-
parking_lot
More compact and efficient implementations of the standard synchronization primitives
-
spin
Spin-based synchronization primitives
-
rayon
work-stealing parallelism for Rust
-
flume
A blazingly fast multi-producer channel
-
thread_local
Per-object thread-local storage
-
crossbeam
Tools for concurrent programming
-
async-lock
Async synchronization primitives
-
ringbuf
Lock-free SPSC FIFO ring buffer with direct access to inner data
-
async-channel
Async multi-producer multi-consumer channel
-
dashmap
Blazing fast concurrent HashMap for Rust
-
triomphe
A fork of std::sync::Arc with some extra functionality and without weak references (originally servo_arc)
-
oneshot
spsc channel with (potentially) lock-free non-blocking send, and a receiver supporting both thread blocking receive operations as well as Future based async polling
-
jobserver
GNU Make jobserver for Rust
-
threadpool
A thread pool for running a number of jobs on a fixed set of worker threads
-
loom
Permutation testing for concurrent code
-
blake2s_simd
a pure Rust BLAKE2s implementation with dynamic SIMD
-
scc
High-performance containers and utilities for concurrent and asynchronous programming
-
thread-priority
managing threads priority and schedule policies
-
lasso
A multithreaded and single threaded string interner that allows strings to be cached with a minimal memory footprint, associating them with a unique key that can be used to retrieve them at any time
-
sync_wrapper
enlisting the compiler's help in proving the absence of concurrency
-
state
safe and effortless global and thread-local state management
-
stateright
A model checker for implementing distributed systems
-
corosensei
A fast and safe implementation of stackful coroutines
-
rtrb
A realtime-safe single-producer single-consumer ring buffer
-
lockfree-object-pool
A thread-safe object pool collection with automatic return and attach/detach semantics
-
thingbuf
I'm at the buffer pool. I'm at the MPSC channel. I'm at the combination MPSC channel and buffer pool.
-
sled
Lightweight high-performance pure-rust transactional embedded database
-
leaky-bucket
A token-based rate limiter based on the leaky bucket algorithm
-
mpi
Message Passing Interface bindings for Rust
-
archery
Abstract over the atomicity of reference-counting pointers
-
radium
Portable interfaces for maybe-atomic types
-
futures-intrusive
Futures based on intrusive data structures - for std and no-std environments
-
diatomic-waker
An async, lock-free synchronization primitive for task wakeup
-
atomic_float
Floating point types which can be safely shared between threads
-
try-lock
A lightweight atomic lock
-
scheduled-thread-pool
A scheduled thread pool
-
ratelimit
ratelimiter that can be shared between threads
-
shuttle
testing concurrent Rust code
-
futures-channel
Channels for asynchronous communication using futures-rs
-
atomic_refcell
Threadsafe RefCell
-
may
Rust Stackful Coroutine Library
-
jobslot
GNU make jobserver for Rust
-
triple_buffer
triple buffering, useful for sharing frequently updated data between threads
-
crossbeam-channel
Multi-producer multi-consumer channels for message passing
-
flurry
Rust port of Java's ConcurrentHashMap
-
async-condvar-fair
Condition variables for async Rust
-
bus
A lock-free, bounded, single-producer, multi-consumer, broadcast channel
-
throttle-server
Provide semaphores for distributed systems via an http interface
-
executors
A collection of high-performance task executors
-
concurrent-map
a lock-free linearizable B+ tree
-
mpstthree
implementing Multiparty Session Types for 2 or more participants
-
tachyonix
A very fast asynchronous, multi-producer, single-consumer bounded channel
-
wasm_thread
An std thread replacement for wasm32 target
-
orx-concurrent-vec
A thread-safe, efficient and lock-free vector allowing concurrent grow, read and update operations
-
atomic
Generic Atomic<T> wrapper type
-
typedmap
A hash map (dash map). A type of value is defined by trait implemented on key type
-
automerge
A JSON-like data structure (a CRDT) that can be modified concurrently by different users, and merged again automatically
-
seize
Fast, efficient, and robust memory reclamation for concurrent data structures
-
inline-array
efficient immutable inlinable byte array
-
disruptor
Low latency inter-thread communication via a ringbuffer (inspired by the LMAX Disruptor)
-
memo-map
implementing a synchronized map for memoization
-
sea-streamer
🌊 The stream processing toolkit for Rust
-
resman
Runtime managed resource borrowing
-
mco
Rust Coroutine Library like go
-
waker-fn
Convert closures into wakers
-
graph
high-performant graph algorithms
-
gix-lock
A git-style lock-file implementation
-
yaque
disk-backed persistent queue for Rust
-
samsa
Rust-native Kafka/Redpanda protocol and client implementation
-
rusty_pool
Self growing / shrinking
ThreadPool
implementation based on crossbeam’s multi-producer multi-consumer channels that enables awaiting the result of a task and offers async support -
workerpool
A thread pool for running a number of jobs on a fixed set of stateful worker threads
-
atomig
Generic, convenient and lock-free
std
atomics viaAtomic<T>
. Can be used with many primitive types (including floats) and with custom types. -
idr-ebr
An efficient concurrent ID to object resolver
-
sdd
Scalable lock-free delayed memory reclaimer
-
trauma
Simplify and prettify HTTP downloads
-
paralight
A lightweight parallelism library for indexed structures
-
patrolilo
Job scheduler with integrated NTFY notifications
-
maitake-sync
No-std async synchronization primitives from Maitake
-
guardian
owned mutex guards for refcounted mutexes
-
uid
creation of unique IDs
-
concurrent-queue
Concurrent multi-producer multi-consumer queue
-
runnel
the pluggable io stream. now support: stdio, string io, in memory pipe
-
lockable
offers hash map, hash set and cache data structures where individual entries can be locked
-
fault-injection
fault injection, concurrency delay injection, and error source annotation
-
loole
A safe async/sync multi-producer, multi-consumer channel
-
happylock
Free deadlock prevention
-
messaging_thread_pool
aiding the creation of typed thread pool of objects that is communicated with via channels
-
parallel-sh
Execute commands in parallel
-
sync_file
Files that can be read concurrently
-
kanal
The fast sync and async channel that Rust deserves
-
atomic-time
AtomicDuration
,AtomicOptionDuration
,AtomicSystemTime
,AtomicOptionSystemTime
,AtomicInstant
andAtomicOptionInstant
for Rust -
fdup
find duplicate files recursively and in parallel
-
gst-plugin-threadshare
GStreamer Threadshare Plugin
-
rcu_cell
a lockless rcu cell implementation
-
async_nursery
Primitive for structured concurrency
-
recloser
A concurrent circuit breaker implemented with ring buffers
-
rs-store
Redux Store for Rust
-
shred
Dispatches systems in parallel which need read access to some resources, and write access to others
-
no_deadlocks
A Runtime Deadlock Debugger
-
rearch
Re-imagined approach to application design and architecture
-
rustc-rayon
work-stealing parallelism for Rust - fork for rustc
-
io-reactor
Concurrent I/O resource management using reactor pattern
-
speare
actor-like thin abstraction over tokio::task and flume channels
-
nbio
Non-Blocking I/O
-
gabriel2
Indeed, an actor library based on Tokio, written in Rust
-
lasso2
A multithreaded and single threaded string interner that allows strings to be cached with a minimal memory footprint, associating them with a unique key that can be used to retrieve them at any time
-
parking
Thread parking and unparking
-
safe-lock
A lock struct with a
const fn
constructor and nounsafe
- ARCHIVED -
qeztorncodegen
* The development of Torn's API v2 is still ongoing. * If selections remain unaltered, they will default to the API v1 version. * Unlike API v1, API v2 accepts both selections and IDs as path and query parameters…
-
st3
A very fast lock-free, bounded, work-stealing LIFO queue
-
arrayfire
high performance software library for parallel computing with an easy-to-use API. Its array based function set makes parallel programming simple. ArrayFire's multiple backends (CUDA…
-
append-only-vec
Append-only, concurrent vector
-
rtsc
Real-time Synchronization Components
-
atomic-arena
Generational arena that allows reserving keys from other threads
-
ringbuffer-spsc
A fast thread-safe single producer-single consumer ring buffer
-
callysto
Stream processing framework
-
rustix-futex-sync
Linux futex-based synchronization
-
signals_receipts
exfiltration of the receipt of POSIX signals
-
indicatif-log-bridge
Bridge the log crate and indicatif to stop log lines from mixing up with progress bars
-
oqueue
Non-interleaving multithreaded output queue
-
steady_state
Framework for building long running low latency actor based services on Linux. Provides visual telemetry to watch data flows between actors. Uses Erlang style supervisors to defend…
-
mcslock
Mellor-Crummey and Scott contention-free lock for mutual exclusion, referred to as MCS lock
-
paradis
Parallel processing with disjoint indices
-
atom
A safe abstraction around AtomicPtr
-
thingvellir
a concurrent, shared-nothing abstraction that manages an assembly of things
-
pumps
Eager streams for Rust
-
bindgen_cuda
Bindgen like interface to build cuda kernels to interact with within Rust
-
papaya
A fast and ergonomic concurrent hash-table for read-heavy workloads
-
aarc
Atomically updatable variants of Arc and Weak for lock-free concurrency
-
tonari-actor
A minimalist actor framework aiming for high performance and simplicity
-
qutex
Synchronization mechanisms that rely on lock-free and other non-(thread)blocking techniques, such as Rust futures, to guarantee mutually exclusive or shared exclusive access to data
-
sharded_mutex
No per-object memory overhead locks. Pseudo atomic ops for Copy/PartialEq types.
-
swap-buffer-queue
A buffering MPSC queue
-
rc_event_queue
VecDeque-like fast, unbounded, FIFO, concurent read-lock-free message queue
-
session_log
session log library for Rust
-
orx-concurrent-iter
A thread-safe and ergonomic concurrent iterator trait and efficient lock-free implementations
-
minstant
A drop-in replacement for
std::time::Instant
that measures time with high performance and high accuracy powered by TSC -
atom_box
A safe idiomatic Rust implementation of Atomic Box using hazard pointers
-
svix-ksuid
A pure Rust and fully tested KSUID implementation
-
tsuki-scheduler
light wight, composable and extensible scheduler for every runtime
-
mutringbuf
lock-free SPSC ring buffer, with in-place mutability
-
skedge
Ergonomic single-process job scheduling for Rust programs
-
wdk-mutex
An idiomatic Rust mutex type for Windows kernel driver development
-
concurrent_arena
u32 concurrent insertion/removal arena that returns ArenaArc
-
pueue
A cli tool for managing long running shell commands
-
oxidd-manager-pointer
Pointer-based manager implementation for OxiDD
-
tasklet
An asynchronous task scheduling library
-
rush_expr_engine
The rules engine is based on the rete algorithm
-
atomptr
A safe, dependency-less abstraction for typed atomic smart pointers
-
picokafka
Kafka library for tarantool-module based on librdkafka
-
rclite
small, fast, and memory-friendly reference counting compatible with Arc and Rc APIs
-
actify
An intutive actor model with minimal boilerplate
-
mintex
minimal mutex
-
readlock
A weird alternative to Arc<RwLock<T>>
-
dispatch
Rust wrapper for Apple's Grand Central Dispatch
-
pi_arr
lock-free & auto-expansion array
-
timeslice
periodic time slice scheduler
-
leapfrog
A fast, lock-free concurrent hash map
-
watchable
RwLock-like type that is compatible with both multi-threaded and async code
-
batch-aint-one
I got 99 problems, but a batch ain't one
-
atomic-take
Atomically take a value out of a container once
-
whisk
fast lockless async channels
-
myriam
Actor model implementation for local and remote actors
-
tokio-cadence
Tokio-based metric sinks for Cadence
-
async-skipdb
An embedded, in-memory, zero-copy, atomicity, consistency, MVCC, almost lock-free and serializable snapshot isolation database engine
-
p3-maybe-rayon
Feature-gated wrapper around rayon
-
lever
Pillars for Transactional Systems and Data Grids
-
elysees
A fork of triomphe, now with more pointer trickery
-
chili
low-overhead parallelization library
-
rayon-cond
Experimental iterator wrapper that is conditionally parallel or serial
-
cfavml
CF's Accelerated Vector Math Library providing SIMD optimzied routines for vector operations
-
async-local
For using thread locals within an async context and across await points
-
pandora-interpreter
A command-line tool to run pandora language
-
gettid
Helper to get an integer ID for the current thread
-
jod-thread
std::thread which joins on drop by default
-
urcu2
Safe API to liburcu
-
portable_atomic_enum
An attribute to create an portable atomic wrapper around a C-style enum
-
atomic-shim
Atomic types for unsupported platforms
-
choir
Task Orchestration Framework
-
oneshot-uniffi
Patched version of oneshot specifically for the UniFFI project. This removes the
loom
target and dependency which helps with UniFFI’s downstream consumers -
yazi-scheduler
Yazi task scheduler
-
async_once
async once tool for lazy_static
-
orx-parallel
A performant and configurable parallel computing library for computations defined as compositions of iterator methods
-
rcron
cron job scheduling for rust
-
crossfire
channels for async and threads
-
spinning_top
spinlock crate based on the abstractions provided by
lock_api
-
rw-cell
Write data to cell from anything place your application without copy, lock and reading in one place
-
utils-atomics
Various atomic utils
-
may_actor
Actor library based on MAY
-
slog-atomic
Atomic run-time controllable drain for slog-rs
-
amity
Concurrency algorithms
-
rose_bloom
A concurrent growing element size linked list with stable pointers
-
paladin-core
distributed algorithm toolkit. Write distributed algorithms without the complexities of distributed systems programming.
-
channel
Rust advanced queue library
-
salsa
A generic framework for on-demand, incrementalized computation (experimental)
-
protoflow
implements flow-based programming (FBP) for Rust using Protocol Buffers messages
-
crossbeam-utils
concurrent programming
-
roboplc
Framework for PLCs and real-time micro-services
-
fast-able
The world's martial arts are fast and unbreakable; 天下武功 唯快不破
-
tc-scalar
TinyChain's scalar value enum, including concurrently-resolvable op definitions and references
-
desync
A hassle-free data type for asynchronous programming
-
task_scheduler_rs
A Rust-based scheduler with basic functionality, focused on adding tasks and handling actions like execute, pause, and shutdown using channels for task communication
-
iterator_ilp
Iterator extensions for instruction-parallel reductions
-
fluxion
actor framework written in rust and designed for distributed systems
-
arccstr
Thread-safe, reference-counted null-terminated immutable strings
-
diskann-rs
DiskANN (Disk-based Approximate Nearest Neighbor search) featuring a 3-layer index architecture and parallel query processing. This project provides an efficient and scalable solution…
-
balter
A load/stress testing framework
-
threadbound
Make any value Sync but only available on its original thread
-
idgenerator-thin
Shorter ID and faster generation with a new snowflake drift algorithm. The core is to shorten the ID length, but also can have a very high instantaneous concurrent processing capacity (50W/0…
-
reord
Run your tests multi-threaded, but in a reproducible way
-
creche
A replacement for std::process::Command and related types in the standard library. Runs single processes, and pipelines of processes, with configuration of file descriptors and environment for each child process.
-
crossbeam-skiplist-mvcc
Support MVCC (Multiple Version Concurrent Control) for
crossbeam-skiplist
-
miyabi_scheduler
Thread pool scheduler with extra specific abilities
-
semka
Semaphore implementation
-
electrologica
High performance concurrent primitives for Rust
-
supply-chain-trust-example-crate-000025
More compact and efficient implementations of the standard synchronization primitives
-
file-per-thread-logger
A logging implementation that writes logs in one file per thread
-
async-event
An efficient async condition variable for lock-free algorithms
-
atomic-wait
Cross-platform atomic wait and wake (aka futex) functionality
-
omango
Concurrency collections
-
melodium
Dataflow-oriented language & tool, focusing on treatments applied on data, allowing high scalability and massive parallelization safely
-
someday
Lock-free MVCC primitive
-
sovran-state
state management for Rust
-
txn_lock
support transactional versioning
-
tatl
in-process alerting
-
every
Run a command every N seconds
-
boxcar
A concurrent, append-only vector
-
lock-free-static
Lock-free static variables
-
irondash_run_loop
Consistent, platform-independent interface to system run loop
-
hzrd
Shared mutability containers based on hazard pointers
-
node-replication
An operation-log based approach that transform single-threaded data structures into concurrent, replicated structures
-
mpsc_requests
mpsc channels but with a response
-
async-stm
Asynchronous Software Transactional Memory
-
lockfree
concurrent data structures and a solution to the ABA problem as an alternative of hazard pointers
-
atomic-destructor
Atomic destructor for multi-threaded env
-
crossbeam-queue
Concurrent queues
-
cargo-steady-state
Code generator for steady_state projects based on a structured dot file
-
sovran-arc
Memory management swift-isms brought to Rust
-
atomic_enum
An attribute to create an atomic wrapper around a C-style enum
-
blazemap
Implements a vector-based slab-like map with an interface similar to that of HashMap, and also provides tools for generating lightweight identifiers that can be type-safely used as keys for this map
-
liner_broker
Redis based message serverless broker
-
parallel-processor
Framework to manage asynchronous execution of multiple compute units communicating using messages
-
async-atomic
Atomics which can be subscribed to and asynchronously notify when updated
-
mpsc
mpsc channel
-
disruptor-rs
A high-performance ring buffer implementation of the LMAX Disruptor pattern
-
command_history
managing command history in Rust applications
-
sharded-vec-writer
Write parts of a Vec from different threads
-
mea
A runtime-agnostic library providing essential synchronization primitives for asynchronous Rust programming
-
skedgy
asynchronous job scheduler
-
maybe-rayon
Either acts as rayon or creates a single-threaded facade
-
multipool
A configurable thread pool with optional work-stealing support and task priority scheduling
-
benjamin_batchly
Low latency batching tool. Bundle lots of single concurrent operations into sequential batches of work.
-
k-lock
A fast mutex for short critical sections
-
shipyard_scenegraph
Scenegraph for Entity Component System
-
evtcall
Rust Event Driven Framework
-
amadeus
Harmonious distributed data processing & analysis in Rust. parquet postgres aws s3 cloudfront elb json csv logs hadoop hdfs arrow common crawl
-
armc
that facilitates Mutex access to variables
-
ptr_cell
Thread-safe cell based on atomic pointers
-
active_standby
A concurrency primitive for high concurrency reads
-
atomic-maybe-uninit
Atomic operations on potentially uninitialized integers
-
anchor-chain
A statically typed async framework for building LLM-based applications
-
init-once
Concurrent, non-blocking lazy initialization of values
-
nexus-actor-remote-rs
Remote library for Nexus Actor
-
local-sync
Non-threadsafe data structure for async usage
-
onering
High throughput synchronous queue
-
dpc-pariter
Parallel iterator processing
-
rucron
Job Scheduling Crate
-
congestion-limiter
Dynamic congestion-based concurrency limits for controlling backpressure
-
ebr
epoch-based reclamation with low cacheline ping-pong
-
rtic-monotonic
Core abstractions of the Real-Time Interrupt-driven Concurrency Monotonic timers
-
easy-threadpool
A relatively simple thread pool which you can send jobs to
-
sharded-thread
Expirement for now
-
kube-leader-election
Leader election implementations for Kubernetes workloads
-
pi_atom
The global thread safe atomic string pool reduces the memory occupation of the same string and is also used for HashMap keys
-
treiber_stack
A lockless, thread-safe, atomic linked-list
-
rearch-effects
Re-imagined approach to application design and architecture
-
open-coroutine-hook
The syscall hook for open-coroutine
-
atomic_once_cell
Thread-safe and lock-free OnceCell and Lazy
-
mpvipc
A small library which provides bindings to control existing mpv instances through sockets
-
tracing-mutex
Ensure deadlock-free mutexes by allocating in order, or else
-
sluice
Efficient ring buffer for byte buffers, FIFO queues, and SPSC channels
-
television-utils
The revolution will be televised
-
rust-lockless-slotmap
A (mostly) lockless slotmap implementation in Rust
-
rufutex
Ulrich Drepper's mutex using futex implementation in Rust
-
split_channel
stream-of-messages abstraction with split send/recv channels
-
rayon-progress-bar
work-stealing parallelism for Rust
-
lock_ext
Extensions to std::sync::Mutex
-
atomic-file-install
For atomically installing a file or a symlink
-
chunklist
A Chunk List is a new, concurrent, chunk-based data structure that is easily modifiable and allows for fast runtime operations
-
lock_api
Wrappers to create fully-featured Mutex and RwLock types. Compatible with no_std.
-
keepcalm
shared types for multi-threaded programs
-
atomic-interval
A tiny implementation of an atomic timer
-
smart_channel
channel subscription system
-
invocation-counter
Datastructure to answer to: how many times a function has been called in the last X minutes?
-
pubserve
generic observer trait
-
fasb
faceted answer set browser
-
moga
A multi-objective genetic algorithm framework
-
batch-processing
A batch library for processing a list of items in parallel
-
atomiq
Convenient tool for atomics in Rust
-
namaste
-
send_cells
Safe and unsafe cells implementing Send/Sync
-
win-kernel
windows-kernel
-
freezebox
deref'able lazy-initialized container
-
kueue
A robust, user-level, work-stealing, distributed task scheduler
-
antidote
Poison-free versions of the standard library Mutex and RwLock types
-
pausable_clock
A source of time information that can be paused and resumed
-
crossbeam-skiplist-fd
A long-term maintained forked version of the crossbeam-skiplist for supporting more flexible key comparison customization
-
lfchring
Concurrent, lock-free implementation of a consistent hashing ring data structure, supporting virtual nodes and keeping track of replication
-
turbo-metrics
Toolkit to compute quality metrics fast using a GPU
-
rusturnate
A sync or async mutex, with or without timeouts
-
thread-manager
A streamlined Rust library for efficient thread pooling and parallel job execution, designed for simplicity, flexibility, and performance
-
ferris-files
A CLI to find large files
-
thread_io
performing I/O in background thread
-
with_daemon
An async client-daemon abstraction framework
-
bcast
Low latency broadcast (SPMC) buffer designed to work with shared memory
-
thread_local_collect
Supports the collection and aggregation of thread-local data across threads
-
asc
Atomic Strong Count
-
sharded-offset-map
A map from u64 to T that can be written from multiple threads
-
sids
sample actor-model scheme providing abstraction over actor types and messages that can be sent across threads
-
spools
Content scraping library for Instagram's Threads
-
synchronized
Convenient and simple macro for code synchronization in multithreading
-
operational-transform
Operational Transformation
-
throttle-client
Client for Throttle. Throttle is an http semaphore service, providing semaphores for distributed systems.
-
pyo3-utils
PyO3
-
restd
A re-implementation of various std features
-
pacwrap-agent
Executable agent for conducting containerized transactions
-
cron_tab
A cron job library for Rust
-
resilience-rs
Resilience patterns in Rust
-
oxidd-rules-mtbdd
Multi-terminal decision diagrams (MTBDDs) for OxiDD
-
rayon-cancel
An adapter to interrupt rayon parallel iterators
-
windows-key-listener
Listen to arbitrary key chords on Windows
-
permit
A struct for cancelling operations
-
td_rthreadpool
thread wrapper for Rust
-
parallel_operations
perform binary operations in parallel using threads
-
circ
Efficient referenced counted pointers for non-blocking concurrency
-
que
A high performance channel with optional backpressure, interprocess capability, and a multiconsumer mode
-
par-iter-sync
Parallel Iterator With Sequential Output
-
concurrent-slotmap
A lock-free concurrent slotmap
-
simple-semaphore
🔐 A lightweight implementation of a Semaphore in Rust
-
async-fifo
MPMC & oneshot channels with (a)sync API
-
parcheck
Test permutations of concurrent scenarios
-
par_slice
Slices that may be accessed from multiple threads with different evels of safety
-
re_capabilities
Capability tokens for the Rerun code base
-
multithreading
in Rust
-
atomicbox
Safe atomic pointers to boxed data
-
slacktor
extremely fast, bare-bones, low-overhead, supervisorless, no-std actor library
-
reactivate
Thread Safe Reactive Data Structure. Made with ❤️ for 🦀
-
incr
fast and self-contained data structures for checking whether a new value is greater than the previous maximum
-
granite_reckoner
aggregator enabling basic statistical operations on Vec<T> in the specified number of threads. Works for all Rust's built-in numeric types.
-
redlock
distributed locking mechanism built on top of Redis
-
clhlock
Craig and, indenpendently, Magnussen, Landin, and Hagersten queue lock for mutual exclusion, referred to as CLH lock
-
thread_map
Types that are simple and easy-to-use alternatives to the
std::thread_local
macro -
smolscale2
hitdns fork of original smolscale
-
evident
Pub/Sub library using IDs to identify events
-
mpmc-async
A multi-producer, multi-consumer async channel with reservations
-
pi_share
rc, arc, lock, atomic
-
cutools
-
sync-cell-slice
Cells and slices that are accessible from multiple threads
-
affinitypool
running blocking jobs on a dedicated thread pool with CPU core affinity
-
sharded_queue
ShardedQueue is currently the fastest concurrent collection which can be used under highest concurrency and load
-
tc-transact
Traits and locking utilities for a TinyChain transaction
-
kontroli
Type checking for the lambda-Pi calculus modulo rewriting
-
pinned-mutex
Mutex wrappers with structural pinning
-
yash-executor
single-threaded concurrent task executor
-
pargraph
Operator based parallel graph processing
-
bastion
Fault-tolerant Runtime for Rust applications
-
task_simple
Execute functions in the background, both on desktop and web
-
stm
Software transactional memory. Allows composable atomic operations.
-
snowdon
A lightweight thread-safe snowflake ID implementation for Rust
-
print_queues
A print queues that can be add from different thread and print on main thread
-
atomx
Thread safe data structures based on atomic data types
-
fibers
execute a number of lightweight asynchronous tasks (a.k.a, fibers) based on futures and mio
-
zallocator
Amortizes the cost of small allocations by allocating memory in bigger chunks
-
ump
Micro message passing library for threads/tasks communication
-
amfiteatr_classic
some classic game theory problems to research on
-
rcu_list
a lockless concurrent list implementation
-
orx-concurrent-bag
An efficient, convenient and lightweight grow-only concurrent data structure allowing high performance concurrent collection
-
virtual-buffer
A cross-platform library for dealing with buffers backed by raw virtual memory
-
direct_ring_buffer
A high-performance, lock-free ring buffer for single-producer, single-consumer scenarios
-
ccutils
Collection of utils from the CylonCore project
-
bztree
BzTree implementation for Rust
-
rush_core
The rules engine is based on the rete algorithm
-
openshmem-rs
Wrappers for the OpenSHMEM API
-
egui_inbox
send messages to egui views from async functions, callbacks, etc. without having to use interior mutability.
-
atomicell
Multi-threaded RefCell on atomics
-
non_blocking_mutex
NonBlockingMutex is currently the fastest way to do expensive calculations under lock, or do cheap calculations under lock when concurrency/load/contention is very high
-
leaklist
concurrent, lock-free, singly-linked list
-
tokio-prometheus-metered-channel
Metered tokio channels with Prometheus metrics integration
-
employees
A small runtime that hides all the boilerplate when using threads
-
stdworld
signal-safe std replacement
-
synchronoise
Synchronization primitives that build upon the standard library
-
seqlock
A reader-writer lock that provides extremely fast read access without starving writers
-
relaxed
Wrappers around Atomics that always use
Ordering::Relaxed
-
folklore
A lock-free concurrent hash map
-
mutex_trait2
Generic mutex trait
-
dynamodb_lock
Distributed lock backed by Dynamodb
-
hylarana-common
A cross-platform screen casting library implemented by Rust
-
may_queue
May's internal queue library
-
cbloom
Concurrent implementation of Bloom filters
-
par
Session types, as an implementation of linear logic with MIX
-
sinner
Easy cross-thread resource sharing for Rust!
-
lazy-mut-rs
Alternative to LazyLock<Mutex<T>>
-
simple-left-right
Lockfree, realtime safe and copy-free Synchronisation
-
nexus-actor-utils-rs
Nexus Actor
-
halt
functionality for pausing, stopping, and resuming iterators, readers, and writers
-
per-thread-mutex
Synchronization lock designed for wrapping thread-unsafe C libraries
-
rsevents
Manual and auto reset events for signaling threads and writing new synchronization primitives like semaphores
-
mvsync
A standalone async and worker thread library, with expandable traits and command buffers
-
EMCompute
fast , simple and cross-platform parallel computing library
-
deferred-reference
A deferred reference is not an actual reference, it is merely a smart pointer tied to the lifetime of the location it points to
-
sigq
Queue that signals waiting consumers about node availability
-
packed-atomic
get any time access to atomic values
-
cachemap2
A concurrent insert-only hashmap for caching values
-
interaction-calculus
A parallel model of computation
-
snowflake-rs-impl
Twitter's Snowflake ID generation algorithm
-
nblock
Non-Blocking Runtime
-
cuneiform-fields
Field level [no_std] cache optimizations for Rust
-
rtic-syntax
The Real-Time Interrupt-driven Concurrency (RTIC) meta language
-
wiring
An async binary serialization framework with channels support
-
dag-scheduler
a scheduler of dag computation graph
-
parseq
Parallel sequential iterator
-
may_waiter
coroutine communication blocker
-
hopper
an unbounded mpsc with bounded memory
-
hydra-dashmap
A fork of dashmap for the hydra framework
-
caos
Concurrent Append Only Segment-list
-
blaze-rs
A Rustified OpenCL Experience
-
hala-sync
Hala synchronous primitive
-
sea-streamer-socket
🌊 SeaStreamer backend-agnostic Socket API
-
local_thread
A local thread management library for Rust. No more 'static functions in order to start threads!
-
session_types
session types in Rust
-
putex
process mutex
-
command-executor
Command Executor thread pool
-
nolock
A collection of Lock-Free Datastructures
-
crossbeam-deque
Concurrent work-stealing deque
-
stronghold-stm
Software transactional memory
-
spry
Resilient, self-healing async process hierarchies in the style of Erlang/OTP
-
aligned-task-scheduler
A scheduler that runs tasks at exact minute intervals with an optional offset, ensuring tasks are aligned to precise time boundaries
-
crosstalk
An extremely lightweight, topic-based, cross-thread, in-memory communication library
-
fast-logger
Fast logger for Rust
-
mongo-lock-async
Distributed mutex locks with MongoDB
-
flashmap
A lock-free eventually consistent concurrent hash map
-
tokio-cron
cron scheduler for tokio
-
rayon-scan
A parallel prefix scan function for ParallelIterator
-
pikav
that help you send event to client with topic subscription
-
ballista-executor
Ballista Distributed Compute - Executor
-
left-right-cell
A cell with lock-free concurrent read access
-
conquerer
DAG analyzer for orchestrating concurrent code
-
rusty_junctions
Join Pattern implementation in Rust
-
blackhole
...to throw your threads into
-
ora
Part of the Ora scheduler framework
-
bicoro
Bidirectional co-routine data structures
-
atomic-waitgroup
A waitgroup implementation supports async with advanced features
-
goko
A lock-free, eventually consistent, concurrent covertree
-
lock_free_hashtable
Lock-free (almost) insertion only hashtable
-
env-lock
Set and lock environment variables for tests
-
con-art-rust
ART-OLC concurrent adaptive radix tree
-
atomicring
AtomicRingBuffer is a constant-size almost lock-free concurrent ring buffer
-
wikiwho
Fast Rust reimplementation of the WikiWho algorithm for fine-grained authorship attribution on large datasets. Optimized for easy integration in multi-threaded applications.
-
asyncgit
allow using git2 in a asynchronous context
-
grizzly_scheduler
A scheduler for running async tasks using cron expressions. It is built on top of tokio. Tasks can be parallel or sequential. Fuzzy random offset can be added to the cron expression.
-
single_value_channel
Concurrent single-value update and receive channel
-
stuck
Multi-threading scheduled task facility building on cooperative stackful coroutine
-
signals2
A thread-safe signal/slot library inspired by boost::signals2
-
spring-stream
Integrate sea-streamer with spring-rs
-
rust_kits
kits
-
tokio-condvar
A Condition Variable for Tokio Applications
-
hipthread
no-std thread library based on pthread
-
conquer-once
Synchronization primitives for lazy and one-time initialization
-
moro
Experimental structured concurrency support for async Rust (similar to trio's nurseries)
-
topograph
A miniscule thread pool and toposort scheduler
-
lock_tree
Prevent deadlocks at compile time. A standalone republication of the netstack3 lock-ordering crate, part of Google's Fuchsia OS.
-
yaambo
concurrent skip lists
-
blocking-threadpool
A thread pool for running a number of jobs on a fixed set of worker threads
-
crius
hystrix-like circuit breaker
-
sparking-lot-core
parking on addresses
-
mt-debug-counters
support high performance debug counters for heavy multithreaded applications
-
left-right
A concurrency primitive for high concurrency reads over a single-writer data structure
-
vlock
A fast and scalable multi-version shared state lock with wait-free read access
-
concurrent_lru
A concurrent LRU cache
-
par-dfs
Parallel, serial, and async dfs and bfs traversal
-
pulse
async wake signals
-
thread-counter
way of efficiently keeping track of active threads and waiting for them to exit
-
either-slot
An atomic slot whose senders can either place their value into the slot, or retrive all the data from the slot
-
periodically
running tasks on a schedule
-
sqrtx
Square root calculation
-
re_smart_channel
A channel that keeps track of latency and queue length
-
ring-channel
Bounded MPMC channel abstraction on top of a ring buffer
-
spinout
A thread-safe clonable and mutable smart-pointer akin to
Arc<Mutex<T>>
, using spin-lock instead of system futex -
boomerang
Deterministic Middleware for Robotics
-
tlrepo
Thread-local git2::Repository, shareable across threads
-
mcl_sched
installable wrapper for the MCL (Minos Compute Library) Scheduler 'mcl_sched'
-
lendpool
lock-free library for allowing safe and concurrent access to a group of objects
-
sentinel-core
The flow sentinel of your microservices
-
carpet
A thread-safe, fully-parallel directed graph
-
mogul
Agnosticly helps to manage concurrent versions of things
-
tagged-rendezvous
Rendezvous hashing with support for tag-based exclusions
-
protoflow-syntax
Protoflow implements flow-based programming (FBP) for Rust using Protocol Buffers messages
-
super_cell
A super (unsafe) cell that also implements send and sync regardless of the inner type's send/sync
-
disrustor
This project is a port of the LMAX Disruptor to Rust
-
sortlock
providing ordered locking
-
deque
A (mostly) lock-free concurrent work-stealing deque
-
context
Cooperative multitasking for Rust using Boost.Context
-
fork-map
running operations in a child process spawned by
fork()
-
workpool
Distribute work to a set of threads and wait for completion
-
omango-futex
Futex for Rust
-
mq
Message Queue
-
adaptive-barrier
Barrier with adaptable number of thread subsciptions
-
commonware-runtime
Execute asynchronous tasks with a configurable scheduler
-
simpl_actor
tokio actors
-
renege
Tracking cache validity using fast concurrent invalidation propogation
-
mwcas
Multi-word CAS primitive
-
rayon-wasm
work-stealing parallelism for Rust
-
tari_shutdown
A convenient shutdown signal
-
terminate-thread
terminatable thread implemented with pthread
-
ordered-parallel-iterator
Performs tasks in parallel returning completed tasks in order of appearance
-
asparit
Async Parallel Iterators for Rust
-
arc-cell
Helper for a simple Cell-like object containing Arc/Weak
-
ppl
A structured parallel programming library for Rust
-
mtlog
Multi-threaded logger with support for log files
-
vin
An ergonomic actor framework
-
killswitch_std
A thread-safe kill switch using only the standard library
-
rly
Run shell commands concurrently with ease. Currently only a CLI tool.
-
readfish-tools
Tools for analysing adaptive sampling data
-
chute
Lockfree mpmc/spmc broadcast queue
-
syncthreads
Safe thread synchronization
-
asar-snes
Rust bindings for Asar (https://github.com/RPGHacker/asar)
-
sync_2
A little crate providing a Rust implemented Mutex and RwLock
-
acto
light-weight Actor library for Rust
-
ora-storage
Part of the Ora scheduler framework
-
spmc
channel
-
watch
A synchronous message passing channel that only retains the most recent value
-
geph-nat
concurrent NAT thingy used throughout Geph
-
talos_messenger_actions
Messenger actions for Talos
-
dropout
Drop your objects out of main thread
-
tlid
Thread Local ID generator by predefined range without atomics/locks/random/time
-
mu_uefi_tpl_mutex
Task Priority Level (TPL) mutual exclusion support
-
threadmap
WIP
-
async-datachannel
Async Wrapper for datachannel
-
yaks
Minimalistic framework for automatic multithreading of hecs via rayon
-
cooptex
Deadlock free Mutexes
-
threadalone
Make any value Send + Sync but only available on its original thread. Don't use on multi-threaded environments!
-
ns3-parallel
A Multitask Parallel Concurrent Executor for ns-3 (network simulator)
-
timedmap
A hash map with expiring key-value pairs
-
ocl-interop
Creates an OpenCL Context with OpenGL Interop enabled
-
crusty
Fast && scalable Broad Web Crawler developed on top of crusty-core
-
hey_listen
An event-dispatcher-collection offering async, sync, parallel, and prioritised solutions!
-
xloc
A fast, multi-threaded line counting utility written in Rust
-
gpgpu
WIP GPGPU framework built on top of wgpu
-
cond_sync
Hides the boilerplate code needed with std::sync::Condvar
-
backdrop_arc
Arc which will drop its large or complex contents in the background with Backdrop! (later, on another thread, or both! Fully customizable! Tokio supported!)
-
zkstate
Share a struct across multiple instances of an application using zookeeper
-
arrayfire_fork
ArrayFire is a high performance software library for parallel computing with an easy-to-use API. Its array based function set makes parallel programming simple. ArrayFire's multiple backends (CUDA…
-
parsli
Parallel status lines for Rust
-
wakerset
no_std, no_alloc storage of Wakers embedded in the Future type
-
big_data
Safe Rust code for creating Erlang NIF to store big data
-
flowync
multithreading a/synchronization
-
norpc
Framework for in-process microservices
-
mutex
An abstraction over closure-based mutexes
-
round_mult
A tiny library to round a number up or down to a multiplier
-
async-pipes
building concurrent data processing pipelines
-
fast-counter
A sharded concurrent counter
-
supply-chain-trust-example-crate-000051
Tools for concurrent programming
-
mongo_sync
instant coding answers via the command line(just like howdoi)
-
godwit-daemon
A daemon runner for GodWit
-
protex
(Process Mutex) concurrency in process level
-
squeue
sized queue
-
interval-task
Repeatedly execute a
Task
with fixed time delay. more thansetInterval
-
arcu
An Rcu implementation using an Arc to keep the read critical section short and handle cleanup
-
lock_freedom
concurrent data structures and a solution to the ABA problem as an alternative of hazard pointers
-
rutin_dashmap
Blazing fast concurrent HashMap for Rust
-
pariter
Parallel iterator processing
-
rusty_chain
abstracts over functional processing units called
chain links
. Each link in the chain is meant to be independent, immutable, idempotent, and highly testable. -
redbus
A high-performance global message bus for concurrent applications
-
nexus-acto-rs
Actors
-
renoir
Network of Operators In Rust
-
supply-chain-trust-example-crate-000041
More compact and efficient implementations of the standard synchronization primitives
-
real-time
Safely share data with a real-time thread
-
oncemutex
A mutex providing one-time synchronized access, then safe unsynchronized access
-
shared-expiry-get
concurrent async get with expiration for Rust
-
usync
fast, drop-in, synchronization primitives
-
ncd
Concurrency library
-
latches
A downward counter (CountDownLatch) which can be used to synchronize threads or coordinate tasks
-
hala-lockfree
Some lockfree structure for rust
-
atomic-counter
Atomic (thread-safe) counters for Rust
-
ductile
A channel implementation that allows both local in-memory channels and remote TCP-based channels with the same interface
-
cache-padded
Prevent false sharing by padding and aligning to the length of a cache line
-
dager
create and execute a graph of nodes
-
currant
spawn concurrent shell processes in rust
-
global_counter
Global, thread-safe counters
-
stakker_log
Logging support for Stakker
-
crossbeam-skiplist-pr1132
A concurrent skip list
-
with_lock
Deadlock freedom
-
pcat
A dead-lock free parallel cat implementation
-
vigil
liveness checking watchdog for detecting deadlocks/livelocks/starvation etc
-
skipchannel
skipchannels allow to communicate between threads, but always skip to the last sent value
-
clustr
Multithreaded string clustering
-
threadpool-executor
A threadpool executor
-
sprinter
Run parallel queued tasks
-
unlock
Instrumented synchronization primitives helping you to unlock performance issues
-
swimming
Dive into Efficiency with Swimming: A High-Performance, No-Nonsense Connection Pool
-
seda_bus
A Staged Event-Driven Architectural message bus
-
hammer-cli
Hammer is a no-config cli tool for running concurrent tasks with monorepo support
-
proglog
Thread safe progress logging
-
swctx
One-shot channel with some special semantics
-
hyaline-smr
Garbage Collector(Hyaline- Safe Memory Reclaimation) for lock free data structures
-
nysa
A bus for passing messages around between independent subsystems of an application
-
surrealkv
A low-level, versioned, embedded, ACID-compliant, key-value database for Rust
-
datacake
A batteries included framework for building fault-tolerance distributed data systems
-
tcb
A middleware service for delivering messages in a causal order
-
read-write-store
A concurrent, unordered collection for Rust, where each element has an internally generated ID and a read-write lock
-
ligmars
Safe bindings to the LGMP C library
-
hyperbridge
Fast multi-producer multi-consumer channel with async support
-
seckoo
A concurrent Cuckoo Hash Table
-
ora-storage-memory
Part of the Ora scheduler framework
-
rustodrive
Rust bindings for controlling multiple ODrives with the CAN protocol
-
batch-lock
A lock manager with batch-lock support
-
apalis-core
Core for apalis: simple, extensible multithreaded background processing for Rust
-
sea-streamer-redis
🌊 SeaStreamer Redis Backend
-
peace-lock
A zero-cost abstraction lock that helps check contention free algorithms
-
pime
Rust Python Integration Made Easy
-
tokio-etcd-lock
WIP
-
wrrm
Write-rarely-read-many wrapper
-
idle
Collection of idle strategies to be used by thread(s) when they have no work to perform
-
threadstack
A more ergonomic and more flexible form of thread local storage
-
zolegus
-
mpi-fork-fnsp
Message Passing Interface bindings for Rust (FORK)
-
unknownrori-simple-thread-pool
A lighweight thread pool for networking and other stuff
-
rusty-cron-scheduler
scheduler that executes function pointers following a cron string
-
rusty-jokes
A humorous Rust crate that brings joy and entertainment to Rust programmers with features like Laughable Lifetimes, Comedic Concurrency, and Punchline Pointers
-
potential
Borrowing for futures - Potential enables interior mutation using mutex and asynchronous borrowing (leasing) through a oneshot channel
-
take-once
A thread-safe container for one-time storage and one-time consumption of a value
-
coarsetime
Time and duration crate optimized for speed
-
navvy
MPSC Channel broker allowing channels of different types to be stored in a single data structure
-
jobsys
Lockless Work Stealing Job System
-
hytra
Datastructure for fast multi-threaded updates
-
cortexm-threads
context-switching on ARM Cortex-M ( 0, 0+, 3, 4, 4F ) micro-processors
-
rtfm-syntax
The Real Time for The Masses (RTFM) meta language
-
tourniquet-tonic
Async native round-robin manager for remote services. Tonic integration.
-
diplomatic-bag
A wrapper type that allows you to send
!Send
types to different threads -
thread-tree
A tree-structured thread pool for splitting jobs hierarchically on worker threads. The tree structure means that there is no contention between workers when delivering jobs
-
swap-arc
A swappable Arc
-
uf_rush
A lock-free, thread-safe implementation of the Union-Find (Disjoint-Set) data structure
-
semrs
A pure rust implementation of semaphores
-
evlru
An eventually consistent LRU designed for lock-free concurrent reads
-
lockless
Composable, lock-free, allocation-light data structures
-
supermon
A set of utilities for coordinating watchers, middleware, and consumers via channels
-
pipelines
constructing multi-threaded pipelines of execution
-
concurrent-initializer
concurrent initializer to ensure initialization only once per key
-
io_partition
allowing to use just a part of a Read + Seek object
-
atomiclock
A non-blocking lock that can be used in async contexts
-
promise_out
promiseOut version for rust
-
cht
Lockfree resizeable concurrent hash table
-
statman
Stat Manager
-
greenie
Green threads and coroutines in stable Rust
-
rs_lockfree
a lock-Free lib based on practical Hazard Pointers algorithm
-
refcell-lock-api
A single-threaded implementation of lock_api for RefCell, to alllow abstracting between single-threaded & multi-threaded code
-
managed-thread
Real fearless concurrency! Spawn threads that will be automatically destroyed when no longer needed
-
ctx-thread
Cooperative, scoped threads based on crossbeam and golang’s context package
-
concread
Concurrently Readable Data-Structures for Rust
-
bi
-
autoincrement
wrapper for different purposes
-
dycovec
A dynamically-allocated, concurrent vector
-
entropy-ecs
一个虚拟世界
-
native-timer
Timer library which uses OS timer capabilities
-
revenq
A concurrent, revision-based event queue implementation
-
wasm_sync
Synchronization primitives for both web and native
-
bursty
Test support for exarcebating contention in multi-threaded code
-
dci
DCI-Closed, a frequent closed itemset mining algorithm, implemented in Rust
-
conquer-util
concurrent and lock-free programming
-
threadling
Threads as traits
-
melodium-common
Common Mélodium elements and traits
-
thfmr-protocol
Internal control protocol encoding and decoding library for the TouHou.FM Radio project
-
sync-unsafe-cell
A backport of the SyncUnsafeCell standard library type for use in older Rust versions
-
peril
Fast and safe Hazard pointers for Rust
-
concurrency-demo-benchmarks
A small utility to benchmark different approaches for building concurrent applications
-
priomutex
A mutex where waiting threads specify a priority
-
kademlia-dht
Kademlia DHT
-
locklessness
Composable, lock-free, allocation-light data structures
-
sas
Salty-and-Sweet one-line Rust Runtime Performance Optimization Library
-
essential-lock
A minimal crate containing Essential's locking method that is safe to use in async code
-
fast-async-mutex
lib which provide asynchronous locking mechanisms (Mutex, RwLock, OrderedMutex and OrderedRwLock)
-
win-events
A poor attempt to implement WaitForMultipleObjects and the ManualReset, AutoReset and Pulse types
-
conqueue
multi-producer, single-consumer queue (MPSC)
-
rgraph
A task graph library
-
refcapsule
Safely send references to other threads
-
irox-threading
Blocking and Asynchronous Threading Tools
-
multithread
API for data-parallel tasks, rayon-lite
-
ordered-channel
A channel that always receives messages in the correct order, even if they were sent out of order
-
rust-debugging-locks
debugging locks in Rust
-
rcu_128
RCU (Read-Copy-Update) implementation for platforms supporting atomic 128-bit operations
-
shared-local-state
shared local state registry for use in EBR, IO, etc
-
persistent-scheduler
high-performance task scheduling system developed in Rust using Tokio. This system supports task persistence, repeatable tasks, Cron-based scheduling, and one-time tasks, ensuring reliability…
-
threadsafe_zmq
Threadsafe zeromq
-
rearch-tokio
Re-imagined approach to application design and architecture
-
dremoc-sync
Synchronization utilities
-
aramid
Synthetic fibers
-
ampsc
async multi-producer single-consumer channel
-
evmap
A lock-free, eventually consistent, concurrent multi-value map
-
base-threadpool
minimalistic threadpool implementation
-
maxwell-utils
Maxwell utils implementation for Rust
-
fan
Simplifies fanning-out (and eventually -in) with channels
-
parallel-iterator
Parallelize any iterator with ease!
-
stronghold-rlu
Read-Log-Update software transactional memory like synchronization mechanism
-
channel-receiver
Channel Receiver
-
thread_timer
cancelable timer with no external dependencies
-
axka-rcu
A reference-counted read-copy-update (RCU) primitive used for protecting shared data
-
persistent_stack
Concurrent persistent stack
-
atomic-array
Defines several array types in which elements may be updated atomically. Intended to provide atomic array types similar to those found in java.util.concurrent.atomic in Java.
-
mpmc
copy-pasted from old rust stdlib
-
fibril
implementing distributed systems with commmunicating fibers
-
orx-concurrent-option
ConcurrentOption is a lock-free concurrent read and write option type
-
semaphore-key
control concurrent thread access by key using a shared semaphore
-
testbench
Testing and benchmarking tools for concurrent Rust code
-
java-threadpool
这是一个跟java ThreadPoolExecutor线程池 使用方式基本相同的线程池
-
navactor
A cli tool for creating and updating actors from piped input
-
dynamic_ocl
Dynamically-loaded OpenCL bindings
-
takecell
A cell type which value can only be taken once
-
distribuidos_sync
Sync common utils using standard library
-
readlock-tokio
A weird alternative to Arc<RwLock<T>>, using tokio's RwLock
-
sync_splitter
Safely split a mutable slice in multiple threads at the same time
-
atomicbox_nostd
Fork of the atomicbox library that works in no_std contexts
-
redsync
Redlock for distributed locks with Redis
-
simt
compute support for rust
-
no-std-async
Async synchronization primitives for #[no_std] rust
-
cogo
Rust Coroutine Library like go
-
anylock
Polymorphic Locks
-
kafka_json_processor_core
The core logic for your Kafka processor, part of kafka-json-processor project
-
thinkofname/think_ecs
Source code of the game Univercity: https://store.steampowered.com/app/808160/UniverCity/
-
mtlog-progress
A progress bar implementation working gracefully with mtlog's logger
-
nemo
Session types for asynchronous networking
-
bustle
Benchmarking harness for concurrent key-value collections
-
linux-rtic
A Real-Time Interrupt-driven Concurrency (RTIC) implementation for Linux
-
slb
Sharded load balancing text-streaming Unix tool
-
sea-streamer-file
🌊 SeaStreamer File Backend
-
exclusion-set
a lock-free concurrent set
-
libblobd-direct
blobd, direct variant
-
dfmutex
Deadlock-free Mutex locks
-
despero-hecs-schedule
shedulable systems and parallel execution for hecs
-
thread-control
control threads' execution/status
-
secc
Implements a Skip-Enabled Concurrent Channel (SECC) for Rust
-
job_abstrs
Abstractions for event-driven jobs
-
cpq
A Concurrent Priority Queue implemented in Safe Rust
-
cell-family
Cheap cells accessed through unique owners
-
lofi
Low Overhead Fibers
-
is_main_thread
A simply tool to check if current thread is the main one
-
foco
Topic-based strongly typed pubsub for no_std rust
-
humthreads
Threads for humans
-
swapper
Swap ownership between threads
-
tucan
fast, and multithreaded interner with loose type requirement
-
discord-termview
Spawn multiple concurrent unix terminals in Discord
-
async-cpupool
async threadpool for CPU-bound tasks
-
little_raft
The lightest distributed consensus library. Run your own replicated state machine!
-
ringbuf-basedrop
A fork of the
ringbuf
crate that uses basedrop’s Shared pointer in place of Arc -
tc-tensor
TinyChain's Tensor collection type
-
pinboard
A lock-free, threadsafe way to publish data, just stick it on the pinboard
-
grandma
A lock-free, eventually consistent, concurrent covertree
-
sleepfast
Sleep for very small amounts of time quickly
-
fenic
test concurrent code
-
locktree
Experimental compiler-checked deadlock-freedom
-
arrow-rayon
Use parallel iterators for Apache Arrow with rayon
-
protoflow-blocks
Protoflow implements flow-based programming (FBP) for Rust using Protocol Buffers messages
-
async-map-reduce
Fast map-reduce based on threading
-
rt-history
An RT-safe history log with error checking
-
stop-thread
Various ways of stopping threads on various platforms, without requiring the thread to poll
-
object-space
An object store library for highly concurrent program written in Rust
-
gosh-remote
Distributed parallel computing over multiple nodes
-
rtrb-basedrop
A fork of the
rtrb
crate that uses basedrop’s Shared pointer in place of Arc -
simdvec
Vectors, but with the operational speedup of SIMD!
-
rust-releases-core
Base traits and definitions for rust-releases
-
voxel-tiler-core
Convert point clouds to voxel data
-
arcow
Atomically Reference-counted Copy-On-Write shared pointer
-
PRUEBA
Colas tarea
-
parallel_reader
reading from a file (or any
Read
stream) and processing it by chunks, in parallel -
rayon_logs
Traces for the rayon work-stealing library
-
killable_thread
A wrapper for thread that allows it to be easily stopped cooperatively
-
synqueue
Internally synchronized (MPMC) queue
-
stoppable_thread
A wrapper for thread that allows it to be easily stopped cooperatively
-
atomic_sibling_counter
A shared counter that allows parallel threads/tasks to check how many siblings they have. The counter is atomic and threads/tasks are not synchronized or coupled in any way.
-
cnr
An operation-log based approach for data replication
-
piz
piz (a Parallel Implementation of Zip) is a ZIP archive reader designed to concurrently decompress files using a simple API
-
mlsp
small library for smart pointers that use both thread local and global atomic counters
-
talaria
A high performance, cyclic message passing library
-
status_executor
Run your work on some context (thread) and get status info back
-
efflux
Easy MapReduce and Hadoop Streaming interfaces in Rust
-
scrummage
Fight over OS process prioritisation
-
skippy-rs
A set of lock free, thread safe, and fast data structures implemented via a Skip List
-
concurrent-round-robin
A concurrent wrr implementation for rust
-
reactor_rs
reactor-rust is an implementation of the Reactive-Streams
-
gmtx
Mutex that grant exclusive access to a group of members
-
rusty_hausdorff
A parallel implementation of the directed Hausdorff distance
-
hwlocality
Idiomatic Rust bindings for the hwloc hardware locality library
-
evolution
Efficiently evolve your old fixed-length data files into modern file formats
-
queuingtask
queueingtask is a library for running different threads in order in Rust
-
sea-streamer-examples
🌊 The stream processing toolkit for Rust
-
swimming-pool
threadpool for running a number of jobs on a fixed number of threads
-
sesh
deadlock-free session-typed communication
-
rcurs
An oxidized RCU implementation
-
flue
An efficient and secure actor runtime library
-
kcas
A lock-free, allocation-free multi-word compare-and-swap library
-
dekker
Dekker's algorithm for mutual exclusion
-
governor
A rate-limiting implementation in Rust
-
bi_channel
Manage bidirectional mpsc channels more conveniently
-
lockpool
offers a pool of locks where individual locks can be locked/unlocked by key
-
ulock-sys
Rust bindings for Darwin's (e.g. macOS, iOS, ...) not-entirely-public ulock API, which provides futex-like functionality.
-
datacake-crdt
A conflict free replicated datatype based on a hybrid logical clock implementation for building eventually consistent data stores
-
run-them
A CLI to launch a single command with many workers, serializing the output
-
async-sema
Async semaphore library
-
slottle
A throttle pool library designed for thread-based concurrency
-
runloop
Cancelable non-blocking polling threads (with optional timeouts)
-
chashmap-async
Concurrent async hash maps with key-scoped locking
-
sever
Coerce hardlinks into new files
-
swap_channel
A safe lock-free parallel communication channel based on mem::swap
-
inert
lets you use non-Sync values in a Sync way
-
concurrent_prime_sieve
Tools for generating filters and collections with primes concurrently. Rust implementation of the Sieve of Atkin. This implementation runs in O( sqrt(max_num) + section_size ) (where section_size = max_num - min_num)…
-
key-message-channel
Multi-producer single-consumer queue capable of queuing messages by message key
-
specs-static
extension for Specs that adds custom ids
-
atomicdouble
128-bit atomics for generic type
-
maxim
Implements a highly-scalable and ergonomic actor system for Rust based on the best of Erlang / Elixir and Akka. A fork of the Axiom actor framework.
-
simd-itertools
SIMD-accelerated alternatives for common operations like contains, max, find etc
-
mscheduler
Use mongodb to schedule task running
-
fenris-paradis
Parallel processing of disjoint indices for the fenris library
-
nvrtc
Bindings for NVIDIA® CUDA™ NVRTC in Rust
-
pi_vec_remain
vec remain range
-
infinitree
Embedded, encrypted database with tiered cache
-
blocking_semaphore
performant blocking semaphore
-
shared_resources
shared resources container which is thread-safe, and lock-free
-
fragile
wrapper types for sending non-send values to other threads
-
sync-extra
Convenience functions to Mutex and RwLock
-
single_executor
Traits for concurrent primitives
-
shardize
proc macro that generates code to create a sharded form of an existing container
-
mutex_logger
logger that usess mutex for thread safty
-
piper
Async pipes, channels, mutexes, and more
-
toktor
A small tokio-based Actor framework
-
file_locking
A lean file locking implementation for Unix and Windows
-
sublock
Variants of RwLock/RefCell that support sublocks, opened for reading if the main
RwLock
is opened for reading, opened for writing if the mainRwLock
is opened for writing -
forkjoin
A work stealing fork-join parallelism library for Rust
-
lockmap
A high-performance, thread-safe HashMap implementation for Rust that provides fine-grained locking at the key level
-
ev_slotmap
A lock-free, eventually consistent, concurrent slot map
-
update_channel
A channel for single updatable values
-
async-liveliness-monitor
A Liveliness Monitor for your Asynchronous Runtimes
-
bmrng
async MPSC request-response channel for Tokio
-
tyra
Typed Actor System
-
ipmpsc
Inter-process Multiple Producer, Single Consumer Channels
-
async-priority-channel
An async channel where pending messages are delivered in order of priority
-
contrie
Concurrent map and set
-
mp2c
A multi producer multi polling consumer library that enables multiple producers to send messages to multiple consumers completely asynchronously
-
spin-sync
Synchronization primitives using spinlock. The interface resembles std::sync. The constructors of public structs are const; i.e. it is possible to declare static Mutex<T> as long as T can be build statically.
-
magnetic
Low-latency lock-free queues
-
todc-utils
building and testing distributed systems
-
atomic-destroy
An value which can be atomically read and destroyed; like an atomic Option
-
deqp-runner
A VK-GL-CTS/dEQP wrapper program to parallelize it across CPUs and report results against a baseline
-
para
A dataflow/pipeline parallelization framework
-
portable-atomic-util
Synchronization primitives built with portable-atomic
-
atomic_prim_traits
Traits over primitive atomic types
-
amadeus-parquet
An Apache Parquet implementation in Rust
-
zkmq
Message Queue, backed by Zookeeper
-
shared_channel
Multi-producer, multi-consumer FIFO queue communication primitives
-
async-events
Waiting for external task completion in asynchronous Rust code
-
queued-task
concurrent queue task processing
-
rdispatcher
Dispatcher for Rust, broadcast and subscribe many to many
-
tokio-bichannel
Bidirectional tokio::sync::mpsc channel
-
sanitizers
Interfaces and FFI bindings for the sanitizers interfaces
-
crossbeam-skiplist
A concurrent skip list
-
cpu-affinity
Cross-Platform CPU affinity
-
libmcl-sys
This system crate provides Rust language bindings to the Minos Compute Library (MCL)
-
go-spawn
that provides macros to spawn and join threads with minimal boilerplate
-
lending_thread_pool
A thread pool where workers can lend their data to their tasks
-
mioco
Scalable, asynchronous IO coroutine-based handling (aka MIO COroutines)
-
schedwalk
Test futures under all possible polling schedules
-
crossbeam-epoch
Epoch-based garbage collection
-
supply-chain-trust-example-crate-000031
More compact and efficient implementations of the standard synchronization primitives
-
rewrk
HTTP benchmarking tool
-
acteur
A safe actor-like framework that just works. Simple, robust, fast, documented.
-
waithandle
that makes signaling between threads a bit more ergonomic
-
mbarc-map
Minimally-blocking, Atomic Reference Counted Map
-
spliter
way to implement Rayon's ParallelIterator
-
channel-sender
Channel Sender
-
spsc-ringbuf-core
Heapless ring buffer
-
mth_calc
demonstrating Cargo. Contains helper method for running a process in parallel on all available processors.
-
std-semaphore
A counting, blocking sempahore extracted from rust 1.7.0
-
spin_loop
-
xrm
Cross Runtime Manager
-
water
thread-safe distributed message sending facility supporting synchronous and asynchronous I/O across process and machine boundaries. It also uses nets which allow message broadcasts to all…
-
fused-reader
fused reader type that if writer thread dies while holding armed fuse the reader will get BrokenPipe error
-
semanticsimilarity_rs
designed to compute similarity/distance metrics between embeddings
-
android-wakelock
Safe and ergonomic Rust bindings to the Android WakeLock API
-
or_poisoned
Unwrap std lock guards in a semantic way
-
async-mutex
Async mutex
-
grip-grab
A faster, more lightweight ripgrep alternative
-
hv-guarded-borrow
Traits and implementations for generic use of "guarded" borrows
-
lockfree-ringbuffer
A lock-free ring buffer implementation in Rust
-
rayon-core
Core APIs for Rayon
-
blinkcast
Fast, bounded, multiple-producer, multiple-consumer, lossy, broadcast channel
-
atomicslice
thread-safe shared slices that are just about as fast as possible to read while also being writable
-
cupchan
async overwriting channel between two threads that is wait & block free by swapping cups around
-
caring
Sharing is caring: a safe library for mmap'ing memory in multiple processes
-
one_at_a_time_please
For serialising calls to functions
-
async_ach-waker
Async Atomic Channel
-
arrows
An actor framework in rust with message durability and ingestion order processing of of messages
-
classic-sync
ReentrantLock, Semaphore and CyclicBarrier using Classic Linux Mutex systems