-
parking_lot
More compact and efficient implementations of the standard synchronization primitives
-
spin
Spin-based synchronization primitives
-
rayon
work-stealing parallelism for Rust
-
dashmap
Blazing fast concurrent HashMap for Rust
-
thread_local
Per-object thread-local storage
-
crossbeam
Tools for concurrent programming
-
async-lock
Async synchronization primitives
-
async-channel
Async multi-producer multi-consumer channel
-
ringbuf
Lock-free SPSC FIFO ring buffer with direct access to inner data
-
flume
A blazingly fast multi-producer channel
-
threadpool
A thread pool for running a number of jobs on a fixed set of worker threads
-
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
-
loom
Permutation testing for concurrent code
-
arcstr
A better reference-counted string type, with zero-cost (allocation-free) support for string literals, and reference counted substrings
-
thread-priority
managing threads priority and schedule policies
-
jwalk
Filesystem walk performed in parallel with streamed and sorted results
-
event-listener
Notify async tasks or threads
-
neon
A safe abstraction layer for Node.js
-
triomphe
A fork of std::sync::Arc with some extra functionality and without weak references (originally servo_arc)
-
jobserver
GNU Make jobserver for Rust
-
sled
Lightweight high-performance pure-rust transactional embedded database
-
kanal
The fast sync and async channel that Rust deserves
-
sync_wrapper
enlisting the compiler's help in proving the absence of concurrency
-
mpi
Message Passing Interface bindings for Rust
-
state
safe and effortless global and thread-local state management
-
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.
-
rtrb
A realtime-safe single-producer single-consumer ring buffer
-
shared_child
using child processes from multiple threads
-
atomic_float
Floating point types which can be safely shared between threads
-
may
Rust Stackful Coroutine Library
-
stateright
A model checker for implementing distributed systems
-
rustler
Safe Rust wrappers for creating Erlang NIF functions
-
local-channel
A non-threadsafe multi-producer, single-consumer, futures-aware, FIFO queue
-
bus
A lock-free, bounded, single-producer, multi-consumer, broadcast channel
-
try-lock
A lightweight atomic lock
-
rayon-cond
Experimental iterator wrapper that is conditionally parallel or serial
-
flurry
Rust port of Java's ConcurrentHashMap
-
kameo
Fault-tolerant Async Actors Built on Tokio
-
futures-intrusive
Futures based on intrusive data structures - for std and no-std environments
-
throttle-server
Provide semaphores for distributed systems via an http interface
-
corosensei
A fast and safe implementation of stackful coroutines
-
radium
Portable interfaces for maybe-atomic types
-
shuttle
testing concurrent Rust code
-
ratelimit
ratelimiter that can be shared between threads
-
scheduled-thread-pool
A scheduled thread pool
-
maitake-sync
No-std async synchronization primitives from Maitake
-
sdd
Scalable lock-free delayed memory reclaimer
-
jobslot
GNU make jobserver for Rust
-
jod-thread
std::thread which joins on drop by default
-
thread-id
Get a unique thread ID
-
parking
Thread parking and unparking
-
tachyonix
A very fast asynchronous, multi-producer, single-consumer bounded channel
-
rustc-rayon
work-stealing parallelism for Rust - fork for rustc
-
seize
Fast, efficient, and predictable memory reclamation for concurrent data structures
-
mpstthree
implementing Multiparty Session Types for 2 or more participants
-
atomic_refcell
Threadsafe RefCell
-
leaky-bucket
A token-based rate limiter based on the leaky bucket algorithm
-
shared_memory
A user friendly crate that allows you to share memory between processes
-
amity
Concurrency algorithms
-
automerge
A JSON-like data structure (a CRDT) that can be modified concurrently by different users, and merged again automatically
-
surrealkv
A low-level, versioned, embedded, ACID-compliant, key-value database for Rust
-
executors
A collection of high-performance task executors
-
typedmap
A hash map (dash map). A type of value is defined by trait implemented on key type
-
orx-concurrent-vec
A thread-safe, efficient and lock-free vector allowing concurrent grow, read and update operations
-
hvm
A massively parallel, optimal functional runtime in Rust
-
concurrent-map
a lock-free linearizable B+ tree
-
guardian
owned mutex guards for refcounted mutexes
-
dagrs
follows the concept of Flow-based Programming and is suitable for the execution of multiple tasks with graph-like dependencies. Dagrs has the characteristics of high performance and asynchronous execution…
-
async-condvar-fair
Condition variables for async Rust
-
chili
low-overhead parallelization library
-
process_control
Ergonomically run processes with limits
-
concurrent-queue
Concurrent multi-producer multi-consumer queue
-
gst-plugin-threadshare
GStreamer Threadshare Plugin
-
atomig
Generic, convenient and lock-free
std
atomics viaAtomic<T>
. Can be used with many primitive types (including floats) and with custom types. -
hwlocality
Idiomatic Rust bindings for the hwloc hardware locality library
-
television
A cross-platform, fast and extensible general purpose fuzzy finder TUI
-
paralight
A lightweight parallelism library for indexed structures
-
ppl
A structured parallel programming library for Rust
-
mco
Rust Coroutine Library like go
-
v_queue
file based queue
-
rclite
small, fast, and memory-friendly reference counting compatible with Arc and Rc APIs
-
lockable
offers hash map, hash set and cache data structures where individual entries can be locked
-
idr-ebr
An efficient concurrent ID to object resolver
-
uid
creation of unique IDs
-
sea-streamer
🌊 The stream processing toolkit for Rust
-
clashmap
Sharded hashmap suitable for fast concurrent access
-
safe-lock
A lock struct with a
const fn
constructor and nounsafe
- ARCHIVED -
atomic-time
AtomicDuration
,AtomicOptionDuration
,AtomicSystemTime
,AtomicOptionSystemTime
,AtomicInstant
andAtomicOptionInstant
for Rust -
indicatif-log-bridge
Bridge the log crate and indicatif to stop log lines from mixing up with progress bars
-
disruptor
Low latency inter-thread communication via a ringbuffer (inspired by the LMAX Disruptor)
-
crossbeam-channel
Multi-producer multi-consumer channels for message passing
-
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 -
crossbeam-utils
concurrent programming
-
ringbuffer-spsc
A fast thread-safe single producer-single consumer ring buffer
-
fault-injection
fault injection, concurrency delay injection, and error source annotation
-
async_nursery
Primitive for structured concurrency
-
readlock
A weird alternative to Arc<RwLock<T>>
-
shred
Dispatches systems in parallel which need read access to some resources, and write access to others
-
mcslock
Mellor-Crummey and Scott contention-free lock for mutual exclusion, referred to as MCS lock
-
happylock
Free deadlock prevention
-
parallel-sh
Execute commands in parallel
-
pausable_clock
A source of time information that can be paused and resumed
-
nbio
Non-Blocking I/O
-
st3
A very fast lock-free, bounded, work-stealing LIFO queue
-
workerpool
A thread pool for running a number of jobs on a fixed set of stateful worker threads
-
aws-sdk-s3-transfer-manager
A high performance Amazon S3 transfer manager for Rust
-
infinitree
Embedded, encrypted database with tiered cache
-
deqp-runner
A VK-GL-CTS/dEQP wrapper program to parallelize it across CPUs and report results against a baseline
-
evolution
Efficiently evolve your old fixed-length data files into modern file formats
-
par-core
Switchable parallel execution core
-
oqueue
Non-interleaving multithreaded output queue
-
inline-array
efficient immutable inlinable byte array
-
irondash_run_loop
Consistent, platform-independent interface to system run loop
-
append-only-vec
Append-only, concurrent vector
-
p3-maybe-rayon
Feature-gated wrapper around rayon
-
mea
A runtime-agnostic library providing essential synchronization primitives for asynchronous Rust programming
-
scx_loader
DBUS on-demand loader of sched-ext schedulers
-
rearch
Re-imagined approach to application design and architecture
-
mutringbuf
lock-free SPSC ring buffer, with in-place mutability
-
pueue
A cli tool for managing long running shell commands
-
grip-grab
A faster, more lightweight ripgrep alternative
-
atomicow
A
Cow
-like data structure where owned data is stored inside anArc
-
recloser
A concurrent circuit breaker implemented with ring buffers
-
bach
Discrete-event simulation environment for async workflows
-
ordered-channel
A channel that always receives messages in the correct order, even if they were sent out of order
-
io-reactor
Concurrent I/O resource management using reactor pattern
-
sync_file
Files that can be read concurrently
-
progress-token
tracking progress of long-running tasks
-
gabriel2
Indeed, an actor library based on Tokio, written in Rust
-
threadbound
Make any value Sync but only available on its original thread
-
pi_share
rc, arc, lock, atomic
-
fast-able
The world's martial arts are fast and unbreakable; 天下武功 唯快不破
-
messaging_thread_pool
aiding the creation of typed thread pool of objects that is communicated with via channels
-
synchronoise
Synchronization primitives that build upon the standard library
-
razel
a command executor with caching for data processing pipelines
-
speare
actor-like thin abstraction over tokio::task and flume channels
-
paradis
Parallel processing with disjoint indices
-
botcore
Production-grade asynchronous bot engine with enterprise observability features
-
rsevents
Manual and auto reset events for signaling threads and writing new synchronization primitives like semaphores
-
aarc
Atomically updatable variants of Arc and Weak for lock-free concurrency
-
callysto
Stream processing framework
-
waker-fn
Convert closures into wakers
-
trauma
Simplify and prettify HTTP downloads
-
boxcar
A concurrent, append-only vector
-
pumps
Eager streams for Rust
-
bend-lang
A high-level, massively parallel programming language
-
orx-concurrent-iter
A thread-safe and ergonomic concurrent iterator trait and efficient lock-free implementations
-
rcu_cell
a lockless rcu cell implementation
-
fieldx
Procedural macro for constructing structs with lazily initialized fields, builder pattern, and serde support with a focus on declarative syntax
-
batch-aint-one
I got 99 problems, but a batch ain't one
-
omango
Concurrency collections
-
pbrt-r3
pbrt-v3
-
leapfrog
A fast, lock-free concurrent hash map
-
syndicate-server
Dataspace server
-
pi_arr
lock-free & auto-expansion array
-
minstant
A drop-in replacement for
std::time::Instant
that measures time with high performance and high accuracy powered by TSC -
session_log
session log library for Rust
-
ballista-scheduler
Ballista Distributed Compute - Scheduler
-
krecik
Asynchronous, parallel external service checker (and reporter), using industry standard libraries: Curl, ngHTTP2 and OpenSSL
-
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
-
thingvellir
a concurrent, shared-nothing abstraction that manages an assembly of things
-
sharded_mutex
No per-object memory overhead locks. Pseudo atomic ops for Copy/PartialEq types.
-
sanitizers
Interfaces and FFI bindings for the sanitizers interfaces
-
melodium
Flow-oriented language & tool, focusing on treatments applied on data, allowing high scalability and massive parallelization safely
-
atom_box
A safe idiomatic Rust implementation of Atomic Box using hazard pointers
-
atomptr
A safe copy-on-write wrapper around
AtomicPtr
with some extra tricks -
chalamet_pir
Stateful, Single-Server Private Information Retrieval for Key-Value Databases
-
concurrent_arena
u32 concurrent insertion/removal arena that returns ArenaArc
-
rustix-futex-sync
Linux futex-based synchronization
-
renege
Tracking cache validity using fast concurrent invalidation propogation
-
std-ext
Extend the standard library functionality
-
onering
High throughput synchronous queue
-
protoflow
implements flow-based programming (FBP) for Rust using Protocol Buffers messages
-
task-local-extensions
Task-local container for arbitrary data
-
pariter
Parallel iterator processing
-
spinning_top
spinlock crate based on the abstractions provided by
lock_api
-
fluxion
actor framework written in rust and designed for distributed systems
-
schedules
A lightweight Rust library for managing operations across multiple time scales
-
atomic-arena
Generational arena that allows reserving keys from other threads
-
async-local
For using thread locals within an async context across await points
-
channel
Rust advanced queue library
-
ostd
Rust OS framework that facilitates the development of and innovation in OS kernels
-
loole
A safe async/sync multi-producer, multi-consumer channel
-
atomic-take
Atomically take a value out of a container once
-
magnetic
Low-latency lock-free queues
-
atomic_once_cell
Thread-safe and lock-free OnceCell and Lazy
-
nexus-acto-rs
Actors
-
splaycast
Stream-specific broadcast channel
-
resilient-rs
fault tolerance, including retry strategies, backoff mechanisms, and failure handling
-
gix-shallow
Handle files specifying the shallow boundary
-
mtzip
making zip archives with multithreaded compression
-
mutex
An abstraction over closure-based mutexes
-
choir
Task Orchestration Framework
-
find_cuda_helper
Helper crate for searching for CUDA libraries
-
rds_lock
asynchronous redis distributed read-write lock implementation based on tokio and redis-rs
-
defer-drop
Defer dropping large types to a background thread
-
atom
A safe abstraction around AtomicPtr
-
arccstr
Thread-safe, reference-counted null-terminated immutable strings
-
range-lock
Range lock for std::vec::Vec
-
elysees
A fork of triomphe, now with more pointer trickery
-
syndicate-schema-plugin
Support for using Preserves Schema with Syndicate macros
-
pijul
A distributed version control system
-
tremor-common
Tremor common functions
-
d-engine
A lightweight strongly-consistent Raft consensus engine for building reliable and scalable distributed systems
-
acts-next
a fast, tiny, extensiable workflow engine
-
gettid
Helper to get an integer ID for the current thread
-
potential
PubSub lib with sync and async API
-
per-thread-mutex
Synchronization lock designed for wrapping thread-unsafe C libraries
-
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
-
spring-stream
Integrate sea-streamer with spring-rs
-
que
A high performance channel with optional backpressure, interprocess capability, and a multiconsumer mode
-
no_deadlocks
A Runtime Deadlock Debugger
-
rw-cell
Write data to cell from anything place your application without copy, lock and reading in one place
-
mpsc
mpsc channel
-
par
Session types, as an implementation of linear logic with MIX
-
sync42
synchronization tools
-
simd-itertools
SIMD-accelerated alternatives for common operations like contains, max, find etc
-
atomic-wait
Cross-platform atomic wait and wake (aka futex) functionality
-
lever
Pillars for Transactional Systems and Data Grids
-
fast-stm
Performance-focused implementation of software transactional memory. Allows composable atomic operations
-
amfiteatr_core
A framework to model and simulate game theory problems with many agents
-
keepcalm
shared types for multi-threaded programs
-
mintex
minimal mutex
-
locktick
Automated lock accounting & profiling
-
asynclog
asynchronous log library
-
quartz
Port of the original Java Quartz Scheduler to Rust
-
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
-
sync-arena
thread-safe arena allocator
-
reactivate
Thread Safe Reactive Data Structure. Made with ❤️ for 🦀
-
lock-hierarchy
Prevent dead locks by enforcing lock hierarchies
-
file-per-thread-logger
A logging implementation that writes logs in one file per thread
-
rose_bloom
A concurrent growing element size linked list with stable pointers
-
ibuf
A memory buffer pool implementation
-
balter
A load/stress testing framework
-
pi_async_transaction
Asynchronous abstraction for transactions
-
sovran-arc
Memory management swift-isms brought to Rust
-
git-wait
wrapper utility around git that waits until index.lock file is no longer present running the command
-
batch-processing
A batch library for processing a list of items in parallel
-
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.
-
lock-free-static
Lock-free static variables
-
tlrepo
Thread-local git2::Repository, shareable across threads
-
linked
Create families of linked objects that can collaborate across threads while being internally single-threaded
-
cfavml
CF's Accelerated Vector Math Library providing SIMD optimzied routines for vector operations
-
rs-store
Redux Store for Rust
-
parallel_worker
A parallel worker implementation in Rust. Allows to start tasks in parallel and receive the results blocking or non-blocking.
-
bcast
Low latency broadcast (SPMC) buffer designed to work with shared memory
-
slog-atomic
Atomic run-time controllable drain for slog-rs
-
freactor
A lightweight framework for asynchronous execution flow
-
namaste
-
lockmap
A high-performance, thread-safe HashMap implementation for Rust that provides fine-grained locking at the key level
-
evtcall
Rust Event Driven Framework
-
txn_lock
support transactional versioning
-
append-only-bytes
Shareable append-only bytes
-
atomx
Thread safe data structures based on atomic data types
-
round_mult
A tiny library to round a number up or down to a multiplier
-
ptr_cell
Thread-safe cell based on atomic pointers
-
winmsg-executor
Per-thread async rust executor for windows
-
portable_atomic_enum
An attribute to create an portable atomic wrapper around a C-style enum
-
semka
Semaphore implementation
-
utils-atomics
Various atomic utils
-
skedgy
asynchronous job scheduler
-
maelstrom-worker-child
Helper library for maelstrom-worker
-
par_slice
Slices that may be accessed from multiple threads with different levels of safety
-
concurrent-slotmap
A lock-free concurrent slotmap
-
triggered
Triggers for one time events between tasks and threads
-
vec-belt
Multi-threaded bulk-append, single-threaded consume
Vec<T>
-
ibag
A thread-safe, immutable bag for holding any value
-
node-replication
An operation-log based approach that transform single-threaded data structures into concurrent, replicated structures
-
simple_coro
(ab)using async/await to write simple state-machine based coroutines
-
sharded-offset-map
A map from u64 to T that can be written from multiple threads
-
spools
Content scraping library for Instagram's Threads
-
command_history
managing command history in Rust applications
-
rc_event_queue
VecDeque-like fast, unbounded, FIFO, concurent read-lock-free message queue
-
simple_spawn_blocking
spawning blocking tasks more ergonomic
-
replay-channel
A broadcast channel where new receivers replay all past messages before receiving new ones
-
sluice
Efficient ring buffer for byte buffers, FIFO queues, and SPSC channels
-
daemonbit-lockfile
Cross-platform daemon lifecycle primitives
-
lock_api
Wrappers to create fully-featured Mutex and RwLock types. Compatible with no_std.
-
tonari-actor
A minimalist actor framework aiming for high performance and simplicity
-
stdout-channel
Write stdout to an async queue
-
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
-
ruffer
overwriting ring buffer library written in Rust
-
stele
An atomic Vec-like structure with no copying on allocation
-
stupid_utils
that provides some simple and maybe stupid or useful tools
-
swap-buffer-queue
A buffering MPSC queue
-
deno_broadcast_channel
BroadcastChannel API for Deno
-
svix-ksuid
A pure Rust and fully tested KSUID implementation
-
iterator_ilp
Iterator extensions for instruction-parallel reductions
-
maybe-rayon
Either acts as rayon or creates a single-threaded facade
-
async_once
async once tool for lazy_static
-
someday
Lock-free MVCC primitive
-
treiber_stack
A lockless, thread-safe, atomic linked-list
-
may_actor
Actor library based on MAY
-
rusturnate
A sync or async mutex, with or without timeouts
-
cubecl-hip-sys
Rust bindings for AMD ROCm HIP runtime libraries used by CubeCL
-
io-pipe
A fast and thread-safe library for creating multi-writer and single-reader pipelines in Rust
-
latches
A downward counter (CountDownLatch) which can be used to synchronize threads or coordinate tasks
-
parallel-stream
Data parallelism library for async-std
-
affinitypool
running blocking jobs on a dedicated thread pool with CPU core affinity
-
orama-js-pool
Create a pool of JavaScript engines to invoke JavaScript code concurrently
-
progpool
Job pool with terminal progress bar
-
orchestrator_lock
A Mutex whose access order is managed by a separate thread
-
electrologica
High performance concurrent primitives for Rust
-
flag-bearer
Generic async semaphores
-
active_standby
A concurrency primitive for high concurrency reads
-
night
A scalable Task Queue for executing asynchronous tasks in topological order
-
split_channel
stream-of-messages abstraction with split send/recv channels
-
factorize_rayon
Rayon find_map_any() demonstration program
-
refreshable
wrapper around a value that changes over time
-
re_smart_channel
A channel that keeps track of latency and queue length
-
take-once
A thread-safe container for one-time storage and one-time consumption of a value
-
myriam
Actor model implementation for local and remote actors
-
alopt
providing efficient synchronization primitives that integrate Option into their design
-
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…
-
fast-steal
特别快的多线程库,支持超细颗粒度的任务窃取
-
ufotofu_queues
Infallible queues that support bulk enqueueing and dequeueing
-
timely_communication
Communication layer for timely dataflow
-
senders_receivers
Senders/Receivers implementation for Rust
-
pawawwewism
a wewy sewious wibwawy fow stwuctuwed concuwwency, i pwomise :3
-
k-lock
A fast mutex for short critical sections
-
streameroo
Compilation of mini-frameworks & utilities for data-streaming applications
-
EMCompute
fast , simple and cross-platform parallel computing library
-
amadeus
Harmonious distributed data processing & analysis in Rust. parquet postgres aws s3 cloudfront elb json csv logs hadoop hdfs arrow common crawl
-
fastpool
This crates implements a fast object pool for Async Rust
-
pi_append_vec
Only supports append vectors, lock free
-
debugrs
logger that mimics the npm debug module
-
rearch-tokio
Re-imagined approach to application design and architecture
-
fibers
execute a number of lightweight asynchronous tasks (a.k.a, fibers) based on futures and mio
-
orx-parallel
A performant and configurable parallel computing library for computations defined as compositions of iterator methods
-
orx-concurrent-bag
An efficient, convenient and lightweight grow-only concurrent data structure allowing high performance concurrent collection
-
pargraph
Operator based parallel graph processing
-
rust_supervisor
An Erlang-inspired process supervision library for Rust
-
papaya
A fast and ergonomic concurrent hash-table for read-heavy workloads
-
multipool
A configurable thread pool with optional work-stealing support and task priority scheduling
-
msgpass
Thin wrapper to a Message Passing Interface (MPI)
-
atomic_enum
An attribute to create an atomic wrapper around a C-style enum
-
desync
A hassle-free data type for asynchronous programming
-
send_cells
Safe and unsafe cells implementing Send/Sync
-
atomic-counter
Atomic (thread-safe) counters for Rust
-
atomic-destructor
Atomic destructor for multi-threaded env
-
pacwrap-agent
Executable agent for conducting containerized transactions
-
real-time
Safely share data with a real-time thread
-
spmc
channel
-
watchable
RwLock-like type that is compatible with both multi-threaded and async code
-
armc
that facilitates Mutex access to variables
-
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 -
parel
run linux commands in parallel
-
mm1-node
M/M/1! Queueing, do you speak it?!
-
skedge
Ergonomic single-process job scheduling for Rust programs
-
jwalk-meta
Filesystem walk performed in parallel with streamed and sorted results
-
swimos_sync
SwimOS Synchronization Channels
-
rsvow
A Rust-like implementation of JavaScript's Promise mechanism
-
sovran-state
state management for Rust
-
killswitch_std
A thread-safe kill switch using only the standard library
-
screeps-async
Tick-aware Async runtime for Screeps
-
thread_map
Types that are simple and easy-to-use alternatives to the
std::thread_local
macro -
rust_kits
kits
-
hab-rs-api-client
Bindings for openHAB REST API
-
par-iter-sync
Parallel Iterator With Sequential Output
-
sync-cell-slice
Cells and slices that are accessible from multiple threads
-
parallel-processor
Framework to manage asynchronous execution of multiple compute units communicating using messages
-
xstream-util
A command line tool to split a stream to child processes
-
antidote
Poison-free versions of the standard library Mutex and RwLock types
-
init-once
Concurrent, non-blocking lazy initialization of values
-
benjamin_batchly
Low latency batching tool. Bundle lots of single concurrent operations into sequential batches of work.
-
mu_uefi_tpl_mutex
Task Priority Level (TPL) mutual exclusion support
-
disruptor-rs
A high-performance ring buffer implementation of the LMAX Disruptor pattern
-
thread_io
performing I/O in background thread
-
nexus-actor-remote-rs
Remote library for Nexus Actor
-
spindle_rs
A distributed locking crate built on Cloud Spanner and TrueTime
-
tokio-agent
Agents are a simple abstraction around state, inspired by Elixir's Agent
-
fast-async-mutex
lib which provide asynchronous locking mechanisms (Mutex, RwLock, OrderedMutex and OrderedRwLock)
-
xstm
A Rust-implemented Software Transactional Memory (STM) library using TL2 (Transactional Locking II) algorithm
-
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…
-
shipyard_scenegraph
Scenegraph for Entity Component System
-
smolscale2
hitdns fork of original smolscale
-
datafusion-substrait
DataFusion Substrait Producer and Consumer
-
tc-transact
Traits and locking utilities for a TinyChain transaction
-
discoid
Different types of generic Circular Buffers
-
asyncgit
allow using git2 in a asynchronous context
-
open-coroutine-hook
The syscall hook for open-coroutine
-
redlock
distributed locking mechanism built on top of Redis
-
atomic-queue
bounded lock-free queue for use in Audio applications, ported from https://github.com/max0x7ba/atomic_queue
-
scored_set
A scored sorted set data structure for Rust
-
signals2
A thread-safe signal/slot library inspired by boost::signals2
-
blueprint-producers-extra
Additional job call producers for the Blueprint SDK
-
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
-
tensr
A high-performance, cross-platform, multi-backend tensor/array library for Rust
-
scope-lock
Safely extend lifetimes
-
unlock
Instrumented synchronization primitives helping you to unlock performance issues
-
async-atomic
Atomics which can be subscribed to and asynchronously notify when updated
-
kueue
A robust, user-level, work-stealing, distributed task scheduler
-
freezebox
deref'able lazy-initialized container
-
sharded-vec-writer
Write parts of a Vec from different threads
-
drcp-format
Parse and write DRCP and literal definition files
-
mpsc_requests
mpsc channels but with a response
-
thread-groups
that spawns several threads so you can wait for their completion and enjoy the silence of your life in the real world
-
atomicbox
Safe atomic pointers to boxed data
-
dpc-pariter
Parallel iterator processing
-
atomic-interval
A tiny implementation of an atomic timer
-
perthread
ThreadMap structure for accessing PerThread thread local variables form a static context
-
task-motel
Opinionated (Tokio) task manager with nested task groups and stoppable tasks
-
parallel_operations
perform binary operations in parallel using threads
-
with_daemon
An async client-daemon abstraction framework
-
bztree
BzTree implementation for Rust
-
priority-inheriting-lock
A priority-inheriting lock based on Linux futexes
-
buf-mutex
Buffered mutexes implementing the reducer parallel-programming pattern
-
topograph
A miniscule thread pool and toposort scheduler
-
permit
A struct for cancelling operations
-
urcu2
Safe API to liburcu
-
atomic_pincell
Threadsafe pinnable RefCell
-
crossbeam-queue
Concurrent queues
-
gram
A programming language for distributed systems
-
simple-left-right
Lockfree, realtime safe and copy-free Synchronisation
-
moro-local
Experimental structured concurrency support for async Rust (similar to trio's nurseries). Works with non-Send futures on stable Rust.
-
api-rate-limiter
rate limiter for Rust APIs
-
amfiteatr_classic
some classic game theory problems to research on
-
smart_channel
channel subscription system
-
file_traverser
designed for efficient file system traversal. It allows users to recursively explore directories and filter files based on customizable criteria. The crate supports both standard library…
-
relay_channel
A single-producer, single-consumer channel where the sender waits for the receiver to receive the message before returning
-
sync_select
A short-circuiting (verbose)
std::thread::scope
-
logisheets_controller
the core of LogiSheets
-
conquer-once
Synchronization primitives for lazy and one-time initialization
-
ollie
An abstraction layer on top of lapin, to align with traditional HTTP API routing
-
sapling-atomicfile
Atomically write a file with retries
-
circ
Efficient referenced counted pointers for non-blocking concurrency
-
print_queues
A print queues that can be add from different thread and print on main thread
-
yz-server-executor
multithreaded async executor (wraps async-executor)
-
app-world
A framework agnostic approach to managing frontend application state
-
sync-unsafe-cell
A backport of the SyncUnsafeCell standard library type for use in older Rust versions
-
spinwait
C#'s SpinWait type for lightweight spinning
-
zirv-queue
Laravel like queue for Rust
-
kontroli
Type checking for the lambda-Pi calculus modulo rewriting
-
sentry_arroyo
working with streaming data
-
nexus-actor-core-rs
Core library for Nexus Actor
-
listfree
lockfree prepend-only list
-
direct_ring_buffer
A high-performance, lock-free ring buffer for single-producer, single-consumer scenarios
-
bus_queue
Lock-free Bounded non-Blocking Pub-Sub Queue
-
anylock
Polymorphic Locks
-
arcu
An Rcu implementation using an Arc to keep the read critical section short and handle cleanup
-
snowdon
A lightweight thread-safe snowflake ID implementation for Rust
-
act-zero
Ergonomic actor system
-
retryable-result
repeatedly try on some recoverable errors until too many or a fatal error
-
task_pool
Flexible abstraction for task-based composable multithreading
-
acto
light-weight Actor library for Rust
-
thread_local_collect
Supports the collection and aggregation of thread-local data across threads
-
td_rthreadpool
thread wrapper for Rust
-
high-level-kafka
High Level Kafka client for Rust
-
ez_logging
dirt-cheap logging system
-
fixed-size-buf
Fixed size async buffer pool
-
peace-lock
A zero-cost abstraction lock that helps check contention free algorithms
-
mutex_trait2
Generic mutex trait
-
crossbeam-skiplist-mvcc
Support MVCC (Multiple Version Concurrent Control) for
crossbeam-skiplist
-
parallel-future
fluent async task experiments
-
mailboxxy
micro actor library for rust
-
parallely
command line process parallelization executor
-
work-queue
A concurrent work-stealing queue for building schedulers
-
hirofa_utils
Utils project which is depended on by several other projects
-
parseq
Parallel sequential iterator
-
ref_count
Efficient, low-level asynchronous synchronization for real-time and embedded systems
-
lock_free_hashtable
Lock-free (almost) insertion only hashtable
-
vlock
A fast and scalable multi-version shared state lock with wait-free read access
-
sinner
Easy cross-thread resource sharing for Rust!
-
aide-de-camp
backend agnostic delayed job queue
-
seqlock
A reader-writer lock that provides extremely fast read access without starving writers
-
thread-object
Abstraction over thread-local storage allowing dynamic creation of TLS variables
-
par_io
Parallel, async file I/O library with control over memory usage with no dependencies
-
local-sync
Non-threadsafe data structure for async usage
-
occstep
An event sourcing library based on a distributed log and optimistic concurrency control
-
batch-lock
A lock manager with batch-lock support
-
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
-
openshmem-rs
Wrappers for the OpenSHMEM API
-
bastion
Fault-tolerant Runtime for Rust applications
-
global-channel
global channels
-
atomicring
AtomicRingBuffer is a constant-size almost lock-free concurrent ring buffer
-
adaptive-barrier
Barrier with adaptable number of thread subsciptions
-
peachy
async task manager, similar to thread pool but cooler and for structs
-
sigq
Queue that signals waiting consumers about node availability
-
uf_rush
A lock-free, thread-safe implementation of the Union-Find (Disjoint-Set) data structure
-
accountable-refcell
A RefCell wrapper that provides actionable information for dynamic borrow failures
-
cacheguard
A lightweight cache guard that pads atomics to prevent false sharing in concurrent Rust systems
-
lockfree
concurrent data structures and a solution to the ABA problem as an alternative of hazard pointers
-
global_counter
Global, thread-safe counters
-
poll-channel
Poll on channel
-
haiyuu
experimental actor-like library
-
erl_nif
Write Erlang and Elixir NIFs in Rust
-
pinned-mutex
Mutex wrappers with structural pinning
-
session_types
session types in Rust
-
timekeep-rs
efficient and reliable timekeeping functionalities, providing data structures and methods for creating, manipulating, and performing set operations on intervals
-
constellation-internal
Common components for the
constellation
framework -
async-mutex
Async mutex
-
congestion-limiter
Dynamic congestion-based concurrency limits for controlling backpressure
-
value-box-ffi
C-like api to family of value-box crates
-
simple-semaphore
🔐 A lightweight implementation of a Semaphore in Rust
-
ebr
epoch-based reclamation with low cacheline ping-pong
-
libgraft
that grafts various functions onto std & friends. Mostly intended for personal development ergonomics.
-
threadpool-executor
A threadpool executor
-
piscina
generic pool that supports both sync and async
-
notmad
life-cycle manager for long running rust operations
-
win-kernel
windows-kernel
-
simpl_actor
tokio actors
-
limqch
A channel built on top of limq
-
ringbuf-blocking
Blocking version of ringbuf
-
syncthreads
Safe thread synchronization
-
tracing-mutex
Ensure deadlock-free mutexes by allocating in order, or else
-
downtime-rs
Downtime for Windows allows you to set a schedule for time away from the screen. During downtime, blocked websites and will be completely inaccessible
-
x32_osc_state
X32 State Tracker via Open Sound Control
-
danube-client
The async client for Danube Messaging Broker platform
-
crossbeam-deque
Concurrent work-stealing deque
-
putex
process mutex
-
flowync
multithreading a/synchronization
-
watch
A synchronous message passing channel that only retains the most recent value
-
sea-streamer-fuse
Stream processing toolbox
-
throttle-client
Client for Throttle. Throttle is an http semaphore service, providing semaphores for distributed systems.
-
direct-neural-biasing
Python and C++ bindings for low-latency, closed-loop neuroscience research
-
mspc_ipc
Multi producer single consumer ring buffer for inter-process communication
-
disrustor
This project is a port of the LMAX Disruptor to Rust
-
crossfire
channels for async and threads
-
single_thread_cell
Create a cell that can only be accessed by a single thread
-
mini-tokio
basic asynchronous rust executor
-
crossbeam-skiplist-fd
A long-term maintained forked version of the crossbeam-skiplist for supporting more flexible key comparison customization
-
lvm-sys2
LVM FFI bindings
-
umpx
Collection of ump extensions
-
approximate
Scalable Approximate Counters
-
thread_tryjoin
Try joining a thread
-
dialectic
Transport-polymorphic, asynchronous session types for Rust
-
logical-expressions
working with logical expressions
-
datacake-crdt
A conflict free replicated datatype based on a hybrid logical clock implementation for building eventually consistent data stores
-
oxidd-manager-index
Index-based manager implementation for OxiDD
-
fslock-arti-fork
files as locks, forked for use in Arti
-
actman
Async Actor Model Library in Rust
-
threadcell
A cell whose value can only be accessed by a owning thread
-
thread-async
Execute a task in a new thread and await the result asynchronously
-
kcr_devops_kubesphere_io
Kubernetes Custom Resource Bindings
-
caos
Concurrent Append Only Segment-list
-
timely-container-master
Container abstractions for Timely
-
employees
A small runtime that hides all the boilerplate when using threads
-
fork-map
running operations in a child process spawned by
fork()
-
miyabi_scheduler
Thread pool scheduler with extra specific abilities
-
ugly_smart_lib
jonny's ugly smart lib for Rust
-
atomicoption
An atomic, nullable, owned pointer
-
jumphash
A Fast, Minimal Memory, Consistent Hash Algorithm
-
nblock
Non-Blocking Runtime
-
rgraph
A task graph library
-
stakker_log
Logging support for Stakker
-
sentinel-core
The flow sentinel of your microservices
-
invocation-counter
Datastructure to answer to: how many times a function has been called in the last X minutes?
-
lock_tree
Prevent deadlocks at compile time. A standalone republication of the netstack3 lock-ordering crate, part of Google's Fuchsia OS.
-
blocking-threadpool
A thread pool for running a number of jobs on a fixed set of worker threads
-
hopper
an unbounded mpsc with bounded memory
-
clhlock
Craig and, indenpendently, Magnussen, Landin, and Hagersten queue lock for mutual exclusion, referred to as CLH lock
-
zallocator
Amortizes the cost of small allocations by allocating memory in bigger chunks
-
diplomatic-bag
A wrapper type that allows you to send
!Send
types to different threads -
irox-threading
Blocking and Asynchronous Threading Tools
-
rcron
cron job scheduling for rust
-
folklore
A lock-free concurrent hash map
-
raii-counter
RAII Counter
-
rayon-cancel
An adapter to interrupt rayon parallel iterators
-
goko
A lock-free, eventually consistent, concurrent covertree
-
blackhole
...to throw your threads into
-
mtlog
Multi-threaded logger with support for log files
-
queued_rust
queue type for better privacy managment and data orginization
-
uactor
The fastest and most modular actor system that doesn't force you to pay for what you don't need
-
tokio-scheduler-types
Types for tokio-scheduler-rs
-
rust-lockless-slotmap
A (mostly) lockless slotmap implementation in Rust
-
usync
fast, drop-in, synchronization primitives
-
swar
Perform operations in parallel on bit subslices in unsigned numbers
-
atomicell
Multi-threaded RefCell on atomics
-
dag-scheduler
a scheduler of dag computation graph
-
per-thread-object
Efficient per-object thread-local storage implementation
-
crosstalk
An extremely lightweight, topic-based, cross-thread, in-memory communication library
-
deque
A (mostly) lock-free concurrent work-stealing deque
-
flag-bearer-mutex
Generic async semaphores
-
switchboard
Enables inter-process communiucation via queues and wakers
-
logthis
beautiful, and easy-to-use logging library for Rust
-
may_queue
May's internal queue library
-
undead
search for dead code in your Python projects
-
portable-atomic-util
Synchronization primitives built with portable-atomic
-
halt
functionality for pausing, stopping, and resuming iterators, readers, and writers
-
interaction-calculus
A parallel model of computation
-
xenevtchn
Rust bindings for Xen event channel API
-
mwcas
Multi-word CAS primitive
-
openrtb2
OpenRTB 2.5 FINAL
-
async-oneshot-channel
async oneshot channel implementation
-
amqp-lapin-helper
rust lapin helper
-
timed-locks
Smart pointers to
tokio::sync
locks that either panic or error after a timeout -
infinitree-backends
Embedded, encrypted database with tiered cache -- backends
-
cron_tab
A cron job library for Rust
-
tokio-etcd-lock
WIP
-
synchronized
Convenient and simple macro for code synchronization in multithreading
-
classic-sync
ReentrantLock, Semaphore and CyclicBarrier using Classic Linux Mutex systems
-
rucron
Job Scheduling Crate
-
sids
sample actor-model scheme providing abstraction over actor types and messages that can be sent across threads
-
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!)
-
lazy-mut-rs
Alternative to LazyLock<Mutex<T>>
-
rusty_junctions
Join Pattern implementation in Rust
-
lotsa
Execute lots of operations spread over any number of threads
-
single_value_channel
Concurrent single-value update and receive channel
-
entro-spin
Entro Spin is a 64-bit, true-random number generator algorithm
-
ruget
Alternative to wget written in Rust
-
log-mdc
A mapped diagnostic context (MDC) for use with the
log
crate -
either-slot
An atomic slot whose senders can either place their value into the slot, or retrive all the data from the slot
-
stm
Software transactional memory. Allows composable atomic operations.
-
snarc
Sendable Non-Atomically Reference Counted
-
yaambo
concurrent skip lists
-
dmanager
Manage concurrent access to overloaded memory sections
-
taskalicious
Common Rust task workers
-
pinboard
A lock-free, threadsafe way to publish data, just stick it on the pinboard
-
protoflow-syntax
Protoflow implements flow-based programming (FBP) for Rust using Protocol Buffers messages
-
venta
Reliable producer interface for Pulsar
-
norpc
Framework for in-process microservices
-
rust-toolchain
Types to model a Rust toolchain
-
os-thread-local
OS-backed thread-local storage. This crate provides a
ThreadLocal
type as an alternative tostd::thread_local!
that allows per-object thread-local storage, while providing a similar API… -
sparking-lot-core
parking on addresses
-
dremoc-sync
Synchronization utilities
-
tensile
A test framework capable of dynamic and parallel test execution
-
kademlia-dht
Kademlia DHT
-
neon-runtime
Bindings to the Node.js native addon API, used by the Neon implementation
-
rotating_file_handler
Implements a simple rotating file handler
-
del-cudarc
funcs for cudarc
-
rsevents-extra
Synchronization objects built on top of rsevents. Semaphore, countdown event, and more.
-
pulse
async wake signals
-
dataflow
data processing library, primarily for machine learning
-
humthreads
Threads for humans
-
spsc-ringbuf-core
Heapless ring buffer
-
rt-history
An RT-safe history log with error checking
-
tlid
Thread Local ID generator by predefined range without atomics/locks/random/time
-
sti
STd Improved
-
may_waiter
coroutine communication blocker
-
mpmc-async
A multi-producer, multi-consumer async channel with reservations
-
ipmpsc
Inter-process Multiple Producer, Single Consumer Channels
-
rcu_list
a lockless concurrent list implementation
-
ora-worker
Part of the Ora scheduler framework
-
sync_2
A little crate providing a Rust implemented Mutex and RwLock
-
easy-threadpool
A relatively simple thread pool which you can send jobs to
-
bi-directional-pipe
async bi-directional pipe
-
ump
Micro message passing library for threads/tasks communication
-
flashmap
A lock-free eventually consistent concurrent hash map
-
leaklist
concurrent, lock-free, singly-linked list
-
readlock-tokio
A weird alternative to Arc<RwLock<T>>, using tokio's RwLock
-
fast-walker
Multi-threaded directory walker, with async support
-
cachemap2
A concurrent insert-only hashmap for caching values
-
rayon-wasm
work-stealing parallelism for Rust
-
awaitdrop
WaitGroup
-
xrm
Cross Runtime Manager
-
cond_sync
Hides the boilerplate code needed with std::sync::Condvar
-
child_wait_timeout
A wait timeout in rust
-
rayon-progress-bar
work-stealing parallelism for Rust
-
context
Cooperative multitasking for Rust using Boost.Context
-
tc-scalar
TinyChain's scalar value enum, including concurrently-resolvable op definitions and references
-
readfish-tools
Tools for analysing adaptive sampling data
-
logfast
Insanely fast logging with a simple interface
-
daemonbit-winmutex
Cross-platform daemon lifecycle primitives
-
named-sem
Named semaphore for Linux & Windows
-
deborrow
Splits mutable references safely into their fields, and helps with reference manipulation
-
rearch-effects
Re-imagined approach to application design and architecture
-
handoff
An unbuffered, asynchronous, single-producer/single-consumer channel
-
bmrng
async MPSC request-response channel for Tokio
-
nexus-actor-utils-rs
Nexus Actor
-
zkstate
Share a struct across multiple instances of an application using zookeeper
-
ampsc
async multi-producer single-consumer channel
-
cogo
Rust Coroutine Library like go
-
flo_stream
Pubsub and related streams for Rust futures
-
bevy_gpu_compute
Empowering anyone to leverage GPU-acceleration with as little barrier-to-entry as possible
-
retrogress
Progress bars with a thin API around complex features
-
protex
(Process Mutex) concurrency in process level
-
debugit
Debug-print any value without trait bounds using specialization (Rust nightly channel)
-
runloop
Cancelable non-blocking polling threads (with optional timeouts)
-
microlock
waiting: Small locks and other timing things!
-
forte
A low-overhead thread-pool with support for non-static async closures
-
bi
-
melodium-common
Common Mélodium elements and traits
-
yaks
Minimalistic framework for automatic multithreading of hecs via rayon
-
cooptex
Deadlock free Mutexes
-
pseudo_pool
A pool-like collection that automatically returns objects to the pool & blocks when the pool is empty
-
ocl-interop
Creates an OpenCL Context with OpenGL Interop enabled
-
pptr
Type-Driven Asynchronous Actor Runtime
-
rly
Run shell commands concurrently with ease. Currently only a CLI tool.
-
carpet
A thread-safe, fully-parallel directed graph
-
rtfm-syntax
The Real Time for The Masses (RTFM) meta language
-
wasm_sync
Synchronization primitives for both web and native
-
generic_static
Generic static variables in generic functions
-
orx-concurrent-option
ConcurrentOption is a lock-free concurrent read and write option type
-
thread-manager
A streamlined Rust library for efficient thread pooling and parallel job execution, designed for simplicity, flexibility, and performance
-
fast-counter
A sharded concurrent counter
-
stuck
Multi-threading scheduled task facility building on cooperative stackful coroutine
-
unbounded-spsc
An unbounded spsc queue built from
bounded_spsc_queue
s -
ccutils
Collection of utils from the CylonCore project
-
tram
event bus that can be cloned and shared across threads
-
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…
-
xloc
A fast, multi-threaded line counting utility written in Rust
-
evmap
A lock-free, eventually consistent, concurrent multi-value map
-
crabler
Web scraper for Crabs
-
waitcell
A cell type containing a value which may not yet be available
-
nyoom
A filesystem walker for floppy-disk
-
take_put_back
A common abstraction of the process of taking some piece out, processing it and then putting it back
-
safe-fork
A tiny library providing
fork
to safe Rust -
interval-task
Repeatedly execute a
Task
with fixed time delay. more thansetInterval
-
pipe-channel
Channel implementation based on pipes
-
tagged-rendezvous
Rendezvous hashing with support for tag-based exclusions
-
gpgpu
WIP GPGPU framework built on top of wgpu
-
rate-gate
Easy and thread-safe rate limiter
-
remutex
Recursive mutex, adapted from Rust's standard library
-
rtrb-basedrop
A fork of the
rtrb
crate that uses basedrop’s Shared pointer in place of Arc -
simplelock
abstractions for inter-process synchronization
-
slb
Sharded load balancing text-streaming Unix tool
-
ns3-parallel
A Multitask Parallel Concurrent Executor for ns-3 (network simulator)
-
cuda-runtime-sys
Rust binding to CUDA Runtime APIs
-
lfchring
Concurrent, lock-free implementation of a consistent hashing ring data structure, supporting virtual nodes and keeping track of replication
-
left-right
A concurrency primitive for high concurrency reads over a single-writer data structure
-
genzero
that lets you get the latest value of a type
-
skipfree
lockfree skiplist
-
mogul
Agnosticly helps to manage concurrent versions of things
-
dropout
Drop your objects out of main thread
-
db
Lightweight high-performance pure-rust transactional embedded database
-
with_lock
Deadlock freedom
-
logging-subscriber
logging subscriber which can be silenced
-
vin
An ergonomic actor framework
-
bqsp
Presentation layer protocol used to transport data in a fast and efficient manner
-
pcp-mutex
A Priority Ceiling Protocol (PCP) mutex, based on Linux PI futex. Allows efficient and deadlock free execution.
-
swapper
Swap ownership between threads
-
two_phase_channel
A safe synchronisation-free parallel communication channel by statically forbidding conflicting accesses
-
chute
Lockfree mpmc/spmc broadcast queue
-
sortlock
providing ordered locking
-
ev_slotmap
A lock-free, eventually consistent, concurrent slot map
-
quicklog
fast logging in Rust
-
periodically
running tasks on a schedule
-
asyncified
A small library for operating on long lived sync values in an async context
-
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)…
-
croissant
A scheduling library
-
omango-futex
Futex for Rust
-
fugue-mptp
A generic multi-process task processor
-
gmtx
Mutex that grant exclusive access to a group of members
-
hey_listen
An event-dispatcher-collection offering async, sync, parallel, and prioritised solutions!
-
striped-lock
Striped Lock for Rust
-
this-state
way to store state in a thread-safe manner as well as a way to asynchronously wait for state changes
-
lockpool
offers a pool of locks where individual locks can be locked/unlocked by key
-
mth_calc
demonstrating Cargo. Contains helper method for running a process in parallel on all available processors.
-
hebo
Distributed MQTT broker
-
mongo_sync
instant coding answers via the command line(just like howdoi)
-
hybrid-logical-clock
Hybrid Logical Clocks for distributed systems
-
priority
A thread/task priority type
-
mbarc-map
Minimally-blocking, Atomic Reference Counted Map
-
sas
Salty-and-Sweet one-line Rust Runtime Performance Optimization Library
-
terminate-thread
terminatable thread implemented with pthread
-
mitosis
providing the ability to spawn processes with custom closures
-
guest
By-value memory storage without by-value memory access
-
contrie
Concurrent map and set
-
efflux
Easy MapReduce and Hadoop Streaming interfaces in Rust
-
threadalone
Make any value Send + Sync but only available on its original thread. Don't use on multi-threaded environments!
-
ordered-parallel-iterator
Performs tasks in parallel returning completed tasks in order of appearance
-
phazer
Two-phase commit for file creation
-
redsync
Redlock for distributed locks with Redis
-
ratelimit_meter
A leaky-bucket-as-a-meter rate-limiting implementation in Rust
-
async-spin-sleep
providing a highly accurate asynchronous timer for multiple async tasks using spin sleep in a single thread
-
arctree
A 'DOM-like' tree implemented using atomic reference counting
-
shared-file
shared, thread-safe file access with independent cursors
-
atomic_cell
Lock-free thread-safe mutable memory locations
-
lariv
Linked Atomic Random Insert Vector: a thread-safe, self-memory-managed vector with no guaranteed sequential insert
-
nysa
A bus for passing messages around between independent subsystems of an application
-
relaxed_channel
Wrapper around async-channel, more performant on heavy pipelines
-
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
-
rhythm
Rate limiter which allows VIPs, written in Rust
-
spry
Resilient, self-healing async process hierarchies in the style of Erlang/OTP
-
parking_monitor
Parking-lot-flavored monitor synchronization construct
-
double_decker
unbounded multi-producer multi-subscriber event bus built with crossbeam channels
-
read-write-store
A concurrent, unordered collection for Rust, where each element has an internally generated ID and a read-write lock
-
cuda-oxide
high-level, rusty wrapper over CUDA. It provides the best safety one can get when working with hardware.
-
fast-smr
Toward fast, wait-free, portable, and robust memory reclamation
-
vigil
liveness checking watchdog for detecting deadlocks/livelocks/starvation etc
-
workpool
Distribute work to a set of threads and wait for completion
-
oxidater
A reusable LMAX Disruptor Implementation in Rust
-
glock
Granular locking crate for Rust
-
jthread
Deadlock-free Mutual Exclusion locks for Rust
-
hyaline-smr
Garbage Collector(Hyaline- Safe Memory Reclaimation) for lock free data structures
-
cht
Lockfree resizeable concurrent hash table
-
thread-counter
way of efficiently keeping track of active threads and waiting for them to exit
-
key-message-channel
Multi-producer single-consumer queue capable of queuing messages by message key
-
semrs
A pure rust implementation of semaphores
-
ring-channel
Bounded MPMC channel abstraction on top of a ring buffer
-
bustle
Benchmarking harness for concurrent key-value collections
-
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…
-
java-threadpool
这是一个跟java ThreadPoolExecutor线程池 使用方式基本相同的线程池
-
proc-lock
cross-process locking API
-
atomic-try-update
Primitives that make it easy to implement correct lock-free algorithms
-
aligned-task-scheduler
A scheduler that runs tasks at exact minute intervals with an optional offset, ensuring tasks are aligned to precise time boundaries
-
nbchan
Highly optimized non-blocking communication channels
-
wrrm
Write-rarely-read-many wrapper
-
RaceNG
Revolutionary, innovative, groundbreaking random number generator using race conditions
-
testbench
Testing and benchmarking tools for concurrent Rust code
-
shared-mutex
A RwLock that can be used with a Condvar
-
threadstack
A more ergonomic and more flexible form of thread local storage
-
atomiq
Convenient tool for atomics in Rust
-
node-workers
A pool of long-lived nodejs workers
-
brutils
Some utilities for Rust
-
little_raft
The lightest distributed consensus library. Run your own replicated state machine!
-
dynamic-pool
a lock-free, thread-safe, dynamically-sized object pool
-
quartz_sched
Minimalistic scheduling library for Rust
-
rpar
Run terminal command multiple times in parallel
-
pcat
A dead-lock free parallel cat implementation
-
msg_channel
message channel
-
unblock
A thread pool for isolating blocking in async programs
-
mp2c
A multi producer multi polling consumer library that enables multiple producers to send messages to multiple consumers completely asynchronously
-
telecomande
A small crate providing a primitive for the execution of asynchronous tasks by processor through commands
-
relaxed
Wrappers around Atomics that always use
Ordering::Relaxed
-
libpenis
port of https://github.com/todashuta/libpenis
-
hytra
Datastructure for fast multi-threaded updates
-
atomiclock
A non-blocking lock that can be used in async contexts
-
concurrent_lru
A concurrent LRU cache
-
boomerang
Deterministic Middleware for Robotics
-
topological_batch
Parallel running of topologically dependent units in batches
-
multi
An easy way to run multiple commands in parallel
-
peril
Fast and safe Hazard pointers for Rust
-
local_thread
A local thread management library for Rust. No more 'static functions in order to start threads!
-
static-key
static keys in Rust
-
option-lock
mutex for Option values
-
atomic-waitgroup
A waitgroup implementation supports async with advanced features
-
left-right-cell
A cell with lock-free concurrent read access
-
callback_cell
Like an Atomic<Option<Box<FnOnce()>>>
-
refcapsule
Safely send references to other threads
-
base-coroutine
A fast and safe implementation of stackful coroutines with scheduler which supports preemptive scheduling
-
ref-portals
Safely use (stack) references outside their original scope
-
tourniquet
Async native round-robin manager for remote services
-
bursty
Test support for exarcebating contention in multi-threaded code
-
sharded_queue
ShardedQueue is currently the fastest concurrent collection which can be used under highest concurrency and load
-
hydra-dashmap
A fork of dashmap for the hydra framework
-
lock_pool
Robust, efficient, high performance, asynchronous object pooling
-
abox
A safe wrapper around AtomicPtr
-
crossbeam-skiplist-pr1132
A concurrent skip list
-
os-unfair-lock
wrapper for Darwin os_unfair_lock
-
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.
-
crossbeam-skiplist_piedb
A concurrent skip list
-
conquerer
DAG analyzer for orchestrating concurrent code
-
hipthread
no-std thread library based on pthread
-
asc
Atomic Strong Count
-
takecell
A cell type which value can only be taken once
-
concurrency-demo-benchmarks
A small utility to benchmark different approaches for building concurrent applications
-
critical-section
Cross-platform critical section
-
edeltraud
thread pool for mixed tokio / threaded infrastructure with zero allocations and static dispatching only
-
async-ringbuffer
A nonblocking spsc ring buffer with fixed capacity
-
tcb
A middleware service for delivering messages in a causal order
-
sea-streamer-socket
🌊 SeaStreamer backend-agnostic Socket API
-
artifacts-crate
managing shared read/write access to data stored in a JSON file
-
dfmutex
Deadlock-free Mutex locks
-
distribuidos_sync
Sync common utils using standard library
-
ordered-locks
Compiletime deadlock avoidance
-
crossbeam-skiplist
A concurrent skip list
-
para
A dataflow/pipeline parallelization framework
-
async-rawlogger
Light console-only async logger. Suitable for containerized workloads. Heavily inspired by "https://github.com/nonconvextech/ftlog"
-
operator-framework
Tools and helpers used to create Kubernetes operators
-
semalock
concurrently writing to files in a safe and efficient manner
-
coroutine
in Rust
-
dci
DCI-Closed, a frequent closed itemset mining algorithm, implemented in Rust
-
mailbox_processor
A small little actor abstraction inspired by the FSharp Mailbox Processor which in turn was inspired by erlang
-
dynamic_join_array
A dynamic array that can be used to join futures for single thread async programming
-
gosh-remote
Distributed parallel computing over multiple nodes
-
tomt_async
Primarily a dumping ground for personal async snippets that may be used in other ToMT projects. If this crate is useful to others please let us know.
-
task-notify
Notify async tasks when someone mutates data they're interested in
-
matrix_operations_cuda
perform matrix operations using cuda
-
shared-local-state
shared local state registry for use in EBR, IO, etc
-
rcu_128
RCU (Read-Copy-Update) implementation for platforms supporting atomic 128-bit operations
-
minicoroutine
mini coroutine library in rust
-
exec-rs
that provides utility traits for task execution and, if the sync feature is enabled, the ability to synchronise tasks based on the value of a key
-
cuneiform-fields
Field level [no_std] cache optimizations for Rust
-
name_locker
interface for asynchronous name lockers, that can run an async task with lock on a given name
-
generic-session-types
Generic session types in Rust for async send recv channel
-
rtfm-core
Core abstractions of the Real Time For the Masses framework
-
atomic-hyperloglog
thread-safe hyperloglog, with atomics
-
managed-thread
Real fearless concurrency! Spawn threads that will be automatically destroyed when no longer needed
-
driver_async
async backend for
btle
,bluetooth_mesh
andusbw
crates -
dynamic_ocl
Dynamically-loaded OpenCL bindings
-
thread-owned-lock
Mutex which can only be unlocked by the owning thread
-
conqueue
multi-producer, single-consumer queue (MPSC)
-
sero
lightweight library for maintaining a shared store of locks
-
ump-ngx
Collection of ump-ng extensions
-
essential-lock
A minimal crate containing Essential's locking method that is safe to use in async code
-
priomutex
A mutex where waiting threads specify a priority
-
napi_async_local
Extends napi-rs with the ability to run local futures
-
lending_thread_pool
A thread pool where workers can lend their data to their tasks
-
init_guard
A Synchronization Primitive for guarding against double initialization
-
refcell-lock-api
A single-threaded implementation of lock_api for RefCell, to alllow abstracting between single-threaded & multi-threaded code
-
anode
Concurrency library for Rust
-
multiserver
Rust multithread server samples
-
rcurs
An oxidized RCU implementation
-
datacake
A batteries included framework for building fault-tolerance distributed data systems
-
more-sync
More synchronization utils
-
thfmr-protocol
Internal control protocol encoding and decoding library for the TouHou.FM Radio project
-
rqueue
A task queue written by rust
-
agner-sup
An actor toolkit inspired by Erlang/OTP (supervisors)
-
try-mutex
Fast non-blocking mutex
-
hvm-core
massively parallel Interaction Combinator evaluator
-
lock_many
Retry-based locking multiple mutexes at once
-
evlru
An eventually consistent LRU designed for lock-free concurrent reads
-
scrummage
Fight over OS process prioritisation
-
rxrs
Reactive Extensions for Rust
-
spawn_groups
Structured concurrency construct written in Rust, for Rustaceans
-
tokio-condvar
A Condition Variable for Tokio Applications
-
sling
Sequentially lockign (SeqLock) Ring Buffer
-
menmos-std
Menmos library containing misc. reusable utilities
-
piz
piz (a Parallel Implementation of Zip) is a ZIP archive reader designed to concurrently decompress files using a simple API
-
pakr-fsm
Template to implement finite-state-machines
-
atomicdouble
128-bit atomics for generic type
-
highroller
high-level rolling index that is thread-safe and guarantees cheap runtime-unique IDs
-
atomic_prim_traits
Traits over primitive atomic types
-
apalis-core
Core for apalis: simple, extensible multithreaded background processing for Rust
-
ero
Erlang-inspired framework for organizing async code in a fault-tolerant way
-
syncbuf
Append-only data structures with lock-free thread-safety and constant-time indexing
-
oncemutex
A mutex providing one-time synchronized access, then safe unsynchronized access
-
shared_channel
Multi-producer, multi-consumer FIFO queue communication primitives
-
deadlocker
Bringing builder pattern to defeat deadlocks
-
async-fifo
MPMC & oneshot channels with (a)sync API
-
ductile
A channel implementation that allows both local in-memory channels and remote TCP-based channels with the same interface
-
hala-lockfree
Some lockfree structure for rust
-
packed-atomic
get any time access to atomic values
-
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 -
unsync_channel
!Send/!Sync channels for Rust
-
swap_channel
A safe lock-free parallel communication channel based on mem::swap
-
concurrent-slice
Extend slice-type types with methods for concurrent processing
-
ligmars
Safe bindings to the LGMP C library
-
mrsc
mpsc with requests
-
rss
serializing the RSS web content syndication format
-
pflock
A phase-fair reader-writer lock that reduces worst-case blocking for readers. Especially useful for multiprocessor real-time systems.
-
nvrtc
Bindings for NVIDIA® CUDA™ NVRTC in Rust
-
io_partition
allowing to use just a part of a Read + Seek object
-
asynciter
Asynchronous iterator
-
sdcons
geo-replicated distributed consensus algorithm: SDPaxos
-
dager
create and execute a graph of nodes
-
idle
Collection of idle strategies to be used by thread(s) when they have no work to perform
-
atomic_mut
that facilitates atomic operations on arbitrary structs
-
swimos_byte_channel
SwimOS Byte Channel
-
extra_atomics
Abstraction over atomic ptr. Such as AtomicBox and AtomicArc.
-
godwit-daemon
A daemon runner for GodWit
-
shared_resources
shared resources container which is thread-safe, and lock-free
-
greenie
Green threads and coroutines in stable Rust
-
thread-lock
A wrapper that locks non-Send and non-Sync data to a specific thread
-
capitan-lib
CAPITAN | Supervisor tree library Capitan allows you to create and configure services and supervisor trees through reactors and services
-
employer
Spawn worker threads and check on them later
-
concurrent-list
An append-only, single-writer multi-reader unrolled linked list
-
locker
named mutex/locker for rust-lang concurrency
-
sesh
deadlock-free session-typed communication
-
conveyor_belt
Queue and batch processing library
-
rendezvous_swap
Swap data and sync execution between a pair of threads efficiently
-
threadgroup
Manage groups of threads as one unit, join the first one that finishes, timeout on join attempts
-
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.
-
unit16
whp-unit16
-
core_affinity
Manages CPU affinities
-
shareable
Thread shareable objects using the minimal amount of synchronization
-
std-semaphore
A counting, blocking sempahore extracted from rust 1.7.0
-
acteur
A safe actor-like framework that just works. Simple, robust, fast, documented.
-
sea-streamer-redis
🌊 SeaStreamer Redis Backend
-
atomic-destroy
An value which can be atomically read and destroyed; like an atomic Option
-
cpu-affinity
Cross-Platform CPU affinity
-
tc-tensor
TinyChain's Tensor collection type
-
atomic-enums
atomic enumerations
-
skipchannel
skipchannels allow to communicate between threads, but always skip to the last sent value
-
protoflow-zeromq
Protoflow implements flow-based programming (FBP) for Rust using Protocol Buffers messages
-
simple-rate-limiter
rate limiter that minimizes contention caused by overactive clients
-
threadsafe_zmq
Threadsafe zeromq
-
tee
An adapter for readers which delegate reads to a writer
-
deploy
The
deploy
library to aide writing and debugging of distributed programs, as well as tooling to run them across a cluster -
todc-utils
building and testing distributed systems
-
object-pool
A thread-safe object pool with automatic return and attach/detach semantics
-
stream-kmerge
K-way merge for streams
-
conquer-util
concurrent and lock-free programming
-
cache-padded
Prevent false sharing by padding and aligning to the length of a cache line
-
proglog
Thread safe progress logging
-
flexible-locks
Flexible Locks
-
mtlog-tokio
Scoped logging for tokio runtimes with support for log files
-
jobsys
Lockless Work Stealing Job System
-
asparit
Async Parallel Iterators for Rust
-
async-map-reduce
Fast map-reduce based on threading
-
tokio-prometheus-metered-channel
Metered tokio channels with Prometheus metrics integration
-
zolegus
-
ulock-sys
Rust bindings for Darwin's (e.g. macOS, iOS, ...) not-entirely-public ulock API, which provides futex-like functionality.
-
multiqueue2
A fast mpmc broadcast queue
-
riker-patterns
A collection of common actor patterns for Riker
-
sleepfast
Sleep for very small amounts of time quickly
-
locktree
Experimental compiler-checked deadlock-freedom
-
sync-extra
Convenience functions to Mutex and RwLock
-
bndpresbufch
Bounds-preserving channel for passing buffers
-
csq
A Concurrent Set Queue implemented in Safe Rust
-
simt_cuda_sys
part of simt. cuda driver api bindings
-
threadmap
WIP
-
semaphore-key
control concurrent thread access by key using a shared semaphore
-
cicd-mel
Mélodium CI/CD library
-
mlt-sys
Bindings for the MLT Multimedia framework
-
channel_io
Reader implementation on channel of bytes
-
bombs
Efficient single-producer multi-consumer channel types
-
lock_ext
Extensions to std::sync::Mutex
-
ditto
CRDTs for common data structures like maps, sets, vecs, strings, and JSON
-
rust-releases-core
Base traits and definitions for rust-releases
-
fowlhouse_bay
tui client which allows the user to create multiple ASCII windows, displaying messages provided through std::sync::mpsc::channel. Note: at the moment this crate should not be used, the API is not stable at all…
-
object-space
An object store library for highly concurrent program written in Rust
-
overdose
Fast, Row Oriented, Kotlin, Scala-like dataframe
-
embassy-time
Instant and Duration for embedded no-std systems, with async timer support
-
freeswitchrs
Rust bindings for FreeSWITCH
-
geese_pool
Message-passing system for networking with Geese
-
lazy_id
A thread-safe lazily-initialized ID
-
late-static
Initialize static variables at runtime
-
tucan
fast, and multithreaded interner with loose type requirement
-
namedlock
Namespaces for named locks
-
workctl
number of higher-level control mechanisms for concurrent work scheduling, built on standard library concurrency primatives
-
thread_reviver
A Discord bot to revive any archived threads (to counter Discord's auto-archive function)
-
simdvec
Vectors, but with the operational speedup of SIMD!
-
spin_sleep_util
Utils using spin_sleep
-
prun
Run 🍺
-
autoincrement
wrapper for different purposes
-
funnel
data structure that makes it easy to read from multiple channels from a single source
-
juliex
a very basic future executor
-
two_way_channel
A two-way communication channel, allowing both clients to send and receive data
-
stewart
A minimalist, high-performance, and non-exclusive actor system
-
atomiclock_spinlock
spinlock
-
snowflake-multi-threaded
The rust-lang implementation of Twitter's id generator algorithm snowflake, it thread safety | Twitter 的id生成器算法snowflake的rust-lang 实现
-
ringbuf-basedrop
A fork of the
ringbuf
crate that uses basedrop’s Shared pointer in place of Arc -
daemonbit-test
Cross-platform daemon lifecycle primitives
-
mpi-fork-fnsp
Message Passing Interface bindings for Rust (FORK)
-
ncd
Concurrency library
-
amadeus-parquet
An Apache Parquet implementation in Rust
-
bi_channel
Manage bidirectional mpsc channels more conveniently
-
ticketed_lock
Ticketed lock system - allows one to separate lock request from the actual waiting
-
process-sync
Synchronization primitives for multiprocess environments
-
grandma
A lock-free, eventually consistent, concurrent covertree
-
concurrent-round-robin
A concurrent wrr implementation for rust
-
persistent_stack
Concurrent persistent stack
-
maybe_parallel_iterator
Toggle parallelism with feature flags!
-
async-events
Waiting for external task completion in asynchronous Rust code
-
rayon-scan
A parallel prefix scan function for ParallelIterator
-
wasserglas
A fixed size thread-safe object pool with automatic reattachment
-
atomic_pingpong
Lightweight no_std ping-pong buffer, using AtomicU8 for synchronization
-
tyra
Typed Actor System
-
is_main_thread
A simply tool to check if current thread is the main one
-
specs-static
extension for Specs that adds custom ids
-
sharded-slab
A lock-free concurrent slab
-
canal
multithreaded concurrency primitives, including queues and channels
-
base-threadpool
minimalistic threadpool implementation
-
patrolilo
Job scheduler with integrated NTFY notifications
-
slacktor
extremely fast, bare-bones, low-overhead, supervisorless, no-std actor library
-
rustcbuildx
$RUSTC_WRAPPER tool to sandbox cargo builds and execute jobs remotely
-
web_worker
implementing web workers to run rayon-styled concurrent work on wasm
-
sbbf-rs
Split block bloom filter implementation
-
multithread
API for data-parallel tasks, rayon-lite
-
hv-guarded-borrow
Traits and implementations for generic use of "guarded" borrows
-
arae
Cursed data structures
-
threadling
Threads as traits
-
async-liveliness-monitor
A Liveliness Monitor for your Asynchronous Runtimes
-
one_at_a_time_please
For serialising calls to functions
-
kcas
A lock-free, allocation-free multi-word compare-and-swap library
-
wipe-on-fork
A replacement to OnceCell, LazyCell, Once, OnceLock, LazyLock that wipes itself when being forked in Unix
-
lofi
Low Overhead Fibers
-
runnel
the pluggable io stream. now support: stdio, string io, in memory pipe
-
parallel-iterator
Parallelize any iterator with ease!
-
lazy_ref
Implements a non-blocking synchronization primitive for lazy-initialized immutable references
-
lockless
Composable, lock-free, allocation-light data structures
-
sandbox-ipc
An IPC implementation with an eye toward enabling privilege separation
-
cura
arc-lock-system that should clean up the code a lot
-
shardize
proc macro that generates code to create a sharded form of an existing container
-
dekker
Dekker's algorithm for mutual exclusion
-
inert
lets you use non-Sync values in a Sync way
-
slottle
A throttle pool library designed for thread-based concurrency
-
global
variables without macros
-
uchan
Multi-producer single-consumer channel for message passing
-
native_db
Drop-in embedded database
-
yanoo
Lock-free mpmc broadcast channel
-
status_executor
Run your work on some context (thread) and get status info back
-
gaffer
Prioritised, parallel job scheduler with concurrent exclusion, job merging, recurring jobs and load limiting for lower priorities
-
zkmq
Message Queue, backed by Zookeeper
-
crb-core-web
CRB | Composable Runtime Blocks | WEB
-
wasm-bindgen-rayon
Adapter for using Rayon-based concurrency on the Web
-
crossbeam-epoch
Epoch-based garbage collection
-
ach-cell
Atomic Channel
-
process-events-streaming
Easy to use process with events and data streaming
-
sea-streamer-file
🌊 SeaStreamer File Backend
-
concurrency_traits
Traits for concurrent primitives
-
oxidator
A reusable LMAX Disruptor Implementation in Rust
-
turbolift
Easy distribution interface 🚡
-
atomic_box
A struct which allows multiple threads to safely update and read from a shared non-nullable pointer to heap data
-
ste
A single-threaded executor with some tricks up its sleeve
-
pb-atomic-hash-map
An atomic hash map
-
nstd_thread
NSTD threading crate
-
rusty-variation
deadlock-free session-typed communication
-
wait_notify
a synchronization primitive for Rust that provides basic wait and notify functionality
-
breadcrumb_channel
Unbounded broadcast channel with clone-on-receive semantics
-
command-executor
Command Executor thread pool
-
pinnable
A Mutex that can be pinned
-
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.
-
opifex
Latin word meaning artisan or manufacturer and referring to a worker who created something
-
streaming-iterator
Streaming iterators
-
ocl
OpenCL bindings and interfaces for Rust
-
idable
some sequence with no lock
-
spliter
way to implement Rayon's ParallelIterator
-
scoped-pool
A flexible thread pool providing scoped threads
-
d4-oxide
wrapper around d4
-
spawns-core
Async runtime agnostic thread context task spawner for Rust
-
clone-replace
Share mutable data by cloning and replacing a reference version
-
rayon_logs
Traces for the rayon work-stealing library
-
fragile
wrapper types for sending non-send values to other threads
-
rtic-core
Core abstractions of the Real-Time Interrupt-driven Concurrency framework
-
rayon_croissant
<lqd> bikeshedding the name: something that is mapped folded and collected, a 🥐
-
scherben-map
Concurrent Sharded HashMap for Rust
-
run-them
A CLI to launch a single command with many workers, serializing the output
-
close_already
Speeds up programs writing lots of files on Windows
-
async-datachannel
Async Wrapper for datachannel
-
lateral
process parallelizer to make lives better at the commandline
-
go-spawn
that provides macros to spawn and join threads with minimal boilerplate
-
chex
Global exit signal library
-
lockfree-ringbuffer
A lock-free ring buffer implementation in Rust
-
event-sender
A c# like event-system
-
sea-streamer-examples
🌊 The stream processing toolkit for Rust
-
futex
Linux futex-based lock implementations
-
ump-ng
Micro message passing library for threads/tasks communication
-
mscheduler
Use mongodb to schedule task running
-
sentinel-rocket
Sentinel middleware for Rocket
-
spinout
A thread-safe clonable and mutable smart-pointer akin to
Arc<Mutex<T>>
, using spin-lock instead of system futex -
mqb
Lock free in memory message queue broker
-
zestors
A fast and flexible actor-framework for building fault-tolerant Rust applications
-
rayoff
rayon but it's map-reduce
-
shared-resource-pool-builder
Create thread pools with a shared resource
-
chunklist
A Chunk List is a new, concurrent, chunk-based data structure that is easily modifiable and allows for fast runtime operations
-
stop-thread
Various ways of stopping threads on various platforms, without requiring the thread to poll
-
coarsetime
Time and duration crate optimized for speed
-
colosseum
A variety of arena allocators for Rust, including thread-safe arenas
-
oh-snap
A thread-safe, owned, heap-allocated array which can be split and merged efficiently, i.e., without moves or memory (de-)allocations
-
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. -
swimming
Dive into Efficiency with Swimming: A High-Performance, No-Nonsense Connection Pool
-
tbb
Intel Threading Building Blocks
-
concurrency_toolkit
Easy switching between std::sync, tokio::sync and loom::sync
-
objectpool
lock-free object pool, support no_std
-
hadron-client
The Hadron Rust client library
-
piper
Async pipes, channels, mutexes, and more
-
drop_worker
Tools for worker threads
-
fiona
Concurrent runtime written against liburing
-
balter-runtime
A load/stress testing framework
-
double-checked-cell-async
A thread-safe lazily initialized cell using double-checked locking
-
revenq
A concurrent, revision-based event queue implementation
-
async-datachannel-wasm
Async Wrapper for WebRTC datachannel in the browser environment
-
async-cpupool
async threadpool for CPU-bound tasks
-
rdispatcher
Dispatcher for Rust, broadcast and subscribe many to many
-
ora-api
Part of the Ora scheduler framework
-
bplustree
Concurrent in-memory B+ Tree featuring optimistic lock coupling
-
coro
Stackful, first-class asymmetric coroutines
-
atomiclock_async
async lock
-
jackiechan
Bounded mpsc channel optimized for lazy bulk operations
-
spin-lock
spin lock implemented by the standard facilities
-
lock_order
macro for helping produce a deterministic lock ordering to prevent deadlocks
-
hala-sync
Hala synchronous primitive
-
todc-mem
Algorithms for shared-memory distributed systems
-
tpool
So simple thread pool
-
aramid
Synthetic fibers
-
nettu_scheduler_api_structs
Nettu scheduler api types
-
spin_loop
-
fused-reader
fused reader type that if writer thread dies while holding armed fuse the reader will get BrokenPipe error
-
disruption_types
Types for communicating with the Discord API and gateway
-
talaria
A high performance, cyclic message passing library
-
arrow-rayon
Use parallel iterators for Apache Arrow with rayon
-
update_channel
A channel for single updatable values
-
lossyq
concurrent single publisher, single consumer queue with fixed length, that never blocks the writer
-
cnr
An operation-log based approach for data replication
-
csplib
CSP for concurrent programming
-
threadfin
A thread pool for running multiple tasks on a configurable group of threads
-
amadeus-aws
Harmonious distributed data analysis in Rust
-
ora-store-memory
Part of the Ora scheduler framework
-
agner-init-ack
An actor toolkit inspired by Erlang/OTP (init-ack)
-
bastion-executor
Cache affine NUMA-aware executor for Rust
-
monotone
counters and queues for coordination in distributed systems
-
linux-rtic
A Real-Time Interrupt-driven Concurrency (RTIC) implementation for Linux
-
mrogalski-looper
Clean abstraction for a single-threaded event loop. Built as a lightweight wrapper around the std::sync::mpsc package.
-
agner-actors
An actor toolkit inspired by Erlang/OTP (actors)
-
dontshare
Prevent false sharing between data
-
acto-rs
Experimental actor library, under development. (renamed from minions_rs).
-
send-cell
Immutable memory region with runtime Send checking
-
crb-parallel
CRB | Composable Runtime Blocks | Parallel
-
pacwrap-core
providing core functionality for pacwrap
-
syncell
Sync alternative to RefCell
-
concurrent-bloom-rs
thread-safe bloom filter
-
process-muxer
single-threaded process multiplexing
-
genserver
Elixir inspired async actor library
-
protoflow-flume
Protoflow implements flow-based programming (FBP) for Rust using Protocol Buffers messages
-
dynqueue
Dynamically extendable Rayon parallel iterator
-
paradis-demo
demo functionality for paradis, not intended for use
-
nolock
A collection of Lock-Free Datastructures
-
bondi
Single producer, multi consumer lock-free ring buffer (experimental)
-
locklessness
Composable, lock-free, allocation-light data structures
-
tc-server
TinyChain's cluster server logic, including peer discovery and replication
-
virtual-buffer
A cross-platform library for dealing with buffers backed by raw virtual memory
-
waitable
A synchronized (atomic) value container implementing the Mutex+Condvar pattern for efficient blocking waits
-
concache
A fast, concurrent, shared hash map
-
steelmill
A resource manager (dependency injector / factory) designed for distributed systems and simulation testing
-
derivable-object-pool
A thread-safe derivable object pool collection with automatic reusage of objects
-
sched-clock
A timer for task scheduling
-
wasm_thread
An std thread replacement for wasm32 target
-
cloudi
API
-
aommap
Append only lock-free memory map implementation
-
one_for_one
supervize spawn'ed async tasks
-
consume
Memory order consume for when it's known that the compiler can't elide the dependency
-
zonyitoo/coio
Coroutine scheduler with non-blocking I/O support
-
rust-waitgroup
A Golang like WaitGroup
-
or_poisoned
Unwrap std lock guards in a semantic way
-
paladin-core
distributed algorithm toolkit. Write distributed algorithms without the complexities of distributed systems programming.
-
rjq
Redis job queue
-
orx-concurrent-ordered-bag
An efficient, convenient and lightweight grow-only concurrent data structure allowing high performance and ordered concurrent collection
-
forkjoin
A work stealing fork-join parallelism library for Rust
-
tokio-bichannel
Bidirectional tokio::sync::mpsc channel
-
atb
lock-free triple buffer
-
voluntary-servitude
Thread-safe appendable list with lock-free iterator
-
thunk
Primitives for generic lazy evaluation in Rust. This crate requires nightly for
untagged_unions
. -
amadeus-commoncrawl
Harmonious distributed data analysis in Rust
-
secc
Implements a Skip-Enabled Concurrent Channel (SECC) for Rust
-
swap-arc
A swappable Arc
-
easy-parallel
Run closures in parallel
-
folo
Runtime engine for Rust services
-
archery
Abstract over the atomicity of reference-counting pointers
-
rayon-par-bridge
Process Rayon parallel processing with a traditional sequential Iterator
-
queue-ext
The extended feature of the queue can convert the pop() function of the queue to Stream and the push() function to Sender
-
atomic-borrow
atomic reference counter
-
membarrier
Process-wide memory barrier
-
fenic
test concurrent code
-
rstorage
fast, durable, high concurrent HashMap
-
rayon_iter_concurrent_limit
Limit the concurrency of an individual rayon parallel iterator method with a convenient macro
-
log-mel
Mélodium logging library
-
easy-sqlite
Little sqlite framework
-
zeet
Work-stealing thread pool built on crossbeam
-
cuckoocache
High performance concurrent cache
-
rayon-core
Core APIs for Rayon
-
spin-locks
An Intel hardware-optimized spin lock that uses Hardware Lock Elision (HLE) and a non-CAS based spin lock (an OR lock) as a fast fallback
-
quinine
Atomic monotonic containers (Mono{Box,Arc})
-
polyester
Parallel iterator adaptors that accept arbitrary iterators
-
daemonbit
Cross-platform daemon lifecycle primitives
-
chunker
Minimalistic parallel executor
-
readahead-iterator
Readahead from an iterator on a separate thread, returning items in order and synchronously
-
htb
Hierarchical token bucket implementation
-
rework
Multi-threaded task processing in the Master-Worker pattern
-
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.
-
thread-local-object
Per-object thread local storage
-
sea-streamer-runtime
🌊 SeaStreamer async runtime abstraction
-
threads_pool
This package provides an easy way to create and manage thread pools, so you don't have to
-
fastlog
A high performance asynchronous logger
-
sem
IPC semaphore
-
task_log
Task based logging
-
xarc
xarc
provides atomically swappable atomically refcounted smart pointers as a safer building block for lockfree algorithms than raw atomic pointers.Xarc
is comparable toArc
but… -
triex
Trivial Executor
-
simplesignal
A dead simple signal system implementation
-
rusty-junctions-macro
Generation and Client Macro API for rusty-junctions
-
arl
A rate limiter to be used with tokio
-
jtp
thread pool, similar to the ThreadPoolExecutor in java
-
thread_lake
A very high level thread pool manager
-
datacake-rpc
A zero-copy, actor-like RPC framework using rkyv
-
caring
Sharing is caring: a safe library for mmap'ing memory in multiple processes
-
lock_freedom
concurrent data structures and a solution to the ABA problem as an alternative of hazard pointers
-
rtic-monotonics
that provides implementations of the Monotonic trait from rtic-time
-
hurdles
Counter-based thread barrier
-
sisyphus-tasks
Reusable utils for long-lived, worker-oriented rust programs
-
rasks
Scheduled background tasks
-
terminate
abstract logic to terminate threads, coroutines and the like
-
llq
Wait-free SPSC linked-list queue with individually reusable nodes
-
rayon-tlsctx
thread local contexts for rayon loops
-
evelyn
event distribution library
-
job-runner
background job runner with configurable delays between job runs
-
sync-cell
A collection of easier to use thread-safe types for the creation of larger thread safe systems
-
open-coroutine-queue
Concurrent work-stealing queue, implemented using st3 and crossbeam-deque
-
simple-rw-global
GlobalContainer based on std::sync::RwLock
-
smartpool
A very customizable, future-aware threadpool
-
poolio
A thread-pool
-
mutex-timeouts
let you specify a timeout on a mutex lock
-
threadbeam
specialized channel type for beaming data out of a newly spawned thread
-
monitor
synchronization construct
-
queuecheck
A thread-safe queue testing and benchmarking library
-
mpmc
copy-pasted from old rust stdlib
-
rust-debugging-locks
debugging locks in Rust
-
governor
A rate-limiting implementation in Rust
-
parking_lot_rt
Parking-lot fork for real-time applications
-
threadReactive
Synchronous Reactive system
-
ccl
Fast datastructures for use in highly concurrent systems
-
rider
bounded executor for tokio; limit the count of tasks running 🚦
-
fencing
tokens
-
async-semaphore
An async semaphore
-
key-mutex
Access mutexes by key
-
ach-linked
Atomic Channel
-
multiqueue
A fast mpmc broadcast queue
-
hv-cell
A no-std port of the
atomic_refcell
crate with additionalArc
-centric functionality -
mezzenger-channel
mezzenger transport over futures channels
-
faucet
Back-pressured MPMC queue that can be drained after signaling completion
-
mpmcpq
Multi-producer multi-consumer Priority Queue
-
hv-elastic
Safe and almost-safe abstractions for lengthening lifetimes and
'static
“loaning” of non-'static
types -
dashmap_with_out_t_map_trait
Blazing fast concurrent HashMap for Rust
-
std-mel
Mélodium standard library
-
ringlog
A fast and lightweight non-blocking logging framework
-
linux-futex
Futex: A Linux-specific fast user-space locking primitive
-
cocoro
A more type-safe take on Rust stackless coroutines
-
kik_sync_service
A synchronous threading worker channel for generating the results you want with the data you need
-
async-once-watch
Asynchronous and shareable container which value is set once
-
enclose
A convenient macro, for cloning values into a closure
-
television-channels
The revolution will be televised
-
sentinel-actix
Sentinel middleware for Actix-Web
-
bufchan
buffered MPSC channel
-
amfiteatr_proc_macro
Procedural macro crate for amfiteatr_* crates
-
ach-ring
Atomic Channel
-
rapidsync
Rapid & threadsafe embedded data stores
-
orx-pinned-concurrent-col
A core data structure with a focus to enable high performance, possibly lock-free, concurrent collections using a PinnedVec as the underlying storage
-
os-sync
synchronization primitives based on OS semaphore
-
try-rwlock
Fast non-blocking readers-writer lock
-
mpmc-ringbuf
queue
-
wei-scheduler
wei scheduler
-
uppercut
Small and simple actor model implementation
-
eiz
some more code
-
protoflow-crossbeam
Protoflow implements flow-based programming (FBP) for Rust using Protocol Buffers messages
-
rtic-syntax
The Real-Time Interrupt-driven Concurrency (RTIC) meta language
-
arbalest
Like Arc<T> but where weak references don't forbid mutable access
-
swimming-pool
threadpool for running a number of jobs on a fixed number of threads
-
arrows
An actor framework in rust with message durability and ingestion order processing of of messages
-
npnc
Lock-free queues
-
momen
low overhead thread pool
-
consumable_vec
generic approach to create a mutual database for multiple producers and consumers
-
libmcs
A MCS Lock Library
-
ump-ng-server
Server message dispatch loop for ump-ng
-
blocking_semaphore
performant blocking semaphore
-
parsli
Parallel status lines for Rust
-
context-coroutine
set of extensions to provide stackful coroutines; it is not officially associated with the context crate
-
statman
Stat Manager
-
concurrent_open_map
A concurrent hashmap implementation in Rust
-
hyperbridge
Fast multi-producer multi-consumer channel with async support
-
concurrent-initializer
concurrent initializer to ensure initialization only once per key
-
par-map
Parallel map and flat_map
-
key-rwlock
keyed asynchronous reader-writer locks
-
atomic-memcpy
Byte-wise atomic memcpy
-
kai-cli
Kai - todo.txt task scheduler
-
theatre
A concise async actor model implementation
-
tasic
Tokio, Async_STD, Smol, Interface Crate
-
scheduling
job scheduler
-
sync_cow
Thread-safe clone-on-write container for fast concurrent writing and reading
-
relay
A lightweight oneshot Future channel
-
movie
An actor / thread orchestration library / macro / framework
-
futures-rate
easy tools to help Rust applications guide critical resources or code paths from being overwhelmed
-
hv-lease-tracker
no-std compatible tracking of borrow origins, for providing better diagnostics when implementing interior mutability primitives
-
fibril
implementing distributed systems with commmunicating fibers
-
mutex_logger
logger that usess mutex for thread safty
-
wasefire-sync
Portable non-blocking mutex
-
refptr
Inherently reference counted structs
-
tc-fs
TinyChain's transactional filesystem interface layer
-
parking_lot_core
An advanced API for creating custom synchronization primitives
-
sync_rw_cell
Thread-safe version of RefCell
-
malobu
Atomic MPMC Bus
-
multithreading
in Rust
-
read-write-api
interface to unify single-threaded code and RwLocks-based code
-
spinning
Mutexes and SIX locks implemented by spinning
-
fuze
A mechanism to wait for a single signal which can be checked at any time
-
magic-ring-buffer
A magic ring buffer (also known as a virtual ring buffer, VRB, or mirrored buffer) which is lock-free for multiple producers and a single consumer
-
ping-pong-cell
An atomic cell for up to two threads
-
aktors
Driver for derive-aktor
-
gemino
A multi producer multi consumer (MPMC) broadcasting channel
-
wakerset
no_std, no_alloc storage of Wakers embedded in the Future type
-
spsc-bip-buffer
A concurrent, spsc ring-buffer with sized reservations
-
sea-streamer-types
🌊 SeaStreamer Traits & Types
-
once_mut
Safe mutable reference to static variable that can be obtained only once
-
multichannel
A mpmc priority multi channel with dynamic channel registration and freezing
-
horde
threads
-
shrink_pool
A thread pool which agressively terminates its threads as soon as they are idle
-
tiny-actor
A minimal actor framework for Rust
-
spin-seq
Fork of the
seqlock
crate that can be used on bare metal -
atomic-story
An brief overview of atomics and memory ordering on a multi-threaded context with examples
-
async-priority-channel
An async channel where pending messages are delivered in order of priority
-
felicia
service for accessing and sharing lists of bad actors
-
brod
A wrapper library providing an API for executing Kafka producers in parallel
-
ya-ring-buf
Ring Buffer. SPSC channel with direct access for bytes/Copy.
-
rpools
A minimalist workerpool for rust
-
slave-pool
thread pool
-
simple-mutex
A mutex more efficient than std and simpler than parking_lot
-
atomic_immut
Atomic immutable value
-
skipdb
An embedded, in-memory, zero-copy, atomicity, consistency, MVCC, almost lock-free and serializable snapshot isolation database engine
-
simple_event_map
event map based on channels, provides a receiver that is either blocking or async
-
balter-core
A load/stress testing framework
-
stoplight
stoppable tasks/threads
-
spmc-logger
A single-producer multi-consumer persistent logger
-
ump-server
Server message dispatch loop for ump
-
paradis-core
core functionality for paradis
-
sync
synchronization primitives
-
request-channel
Async MPSC request-reponse channel
-
bounded-spsc-queue
A bounded SPSC queue
-
toktor
A small tokio-based Actor framework
-
protoflow-blocks
Protoflow implements flow-based programming (FBP) for Rust using Protocol Buffers messages
-
async-rwlock
Async reader-writer lock
-
pairlock
A reader-writer lock with wait-free reads
-
skl
A lock-free thread-safe concurrent ARENA based (heap backend or memory map backend) skiplist implementation which helps develop MVCC memtable for LSM-Tree
-
open-coroutine-iouring
The io_uring support for open-coroutine
-
datacake-node
The core cluster membership system built ontop of Quickwit's chitchat
-
rw_lease
Fast Reader-Writer lock with reader draining support. Based on a single (parameterisable) atomic usize.
-
scheduled-executor
Single and multi-threaded task scheduler
-
hybrid-lock
A hybrid lock with optimistic locking
-
raliguard
Lazy rate limit semaphore implementation for your asynchronous code frequency execution
-
amadeus-types
Harmonious distributed data analysis in Rust
-
busan
An actor implementation for Rust
-
ach
Atomic Channel
-
blasoxide-mt
multithreading for blasoxide
-
phoenix-tls
creating always present thread locals
-
shared_vector
Reference counted vector data structure
-
sorted-channel
sorted message-based communication channel
-
jotty
embeddable distributed processing framework for both short and long running batch jobs
-
melodium-engine
Mélodium core engine and executor implementation
-
executor-service
A fast and efficient Thread Pool like Java ExecutorService
-
moka
A fast and concurrent cache library inspired by Java Caffeine
-
navvy
MPSC Channel broker allowing channels of different types to be stored in a single data structure
-
atomic-bus
Atomic MPMC Bus
-
lightproc
Lightweight process abstraction for Rust
-
smart-threadpool
A smart thread pool implementation in Rust
-
rs_taskflow
executing graphs of tasks
-
padlock
Safely acquire RwLock/Mutex locks
-
bastion-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
-
sento
A lock-free, append-only atomic pool
-
parallel-event-emitter
Parallel Event Emitter for concurrent listener invocation based on futures-rs and futures-cpupool
-
rayon-core-wasm
Core APIs for Rayon
-
ga-scheduler
A Genetic Algorithm optimizer designed for scheduling and similar tasks
-
onetime
(aka. oneshot) async spsc channel
-
work-steal-queue
Concurrent work-stealing queue, implemented using st3 and crossbeam-deque
-
daemonbit-rundir
Cross-platform daemon lifecycle primitives
-
qadapt-spin
Synchronization primitives based on spinning. They may contain data, are usable without
std
, and static initializers are available -
callysto-avro
Avro serde for Callysto Stream Processing Framework
-
workerpool-rs
workerpool for rust
-
access-queue
limit the number of simultaneous accesses to a value
-
rayon-macro
Macros enabling parallelism using the rayon crate
-
testtools
Helpers for eliminating boilerplate code in tests
-
mias_channel
that supports bi-directional channels by wrapping others
-
lock-free-multi-producer-single-consumer-ring-buffer
A lock-free, multi-producer, single-consumer (MPSC) ring buffer. Optimized for sending and receiving 'bursts' of messages. Can also be used as a ring queue. It is a Rust port of Mindaugas Rasiukevicius's ringbuf.
-
blinkcast
Fast, bounded, multiple-producer, multiple-consumer, lossy, broadcast channel
-
murray
A minimal actor definition macro using Tokio
-
hybridfutex
An efficient hybrid wait queue futex designed for high-contention scenarios, supporting both synchronous and asynchronous waiting and notification. It supports notify and notify_many on all targets.
-
delay-queue
A concurrent unbounded blocking queue where each element can only be removed when its delay expires
-
gothack-future-parking_lot
An "as simple as possible" Future implementation for parking_lot
-
read-cell
Read-only Cell counterpart
-
cpq
A Concurrent Priority Queue implemented in Safe Rust
-
threatpool
thread pool
-
yastl
scoped threadpool library
-
mula
Share expensive computation with various requesters
-
thread-broadcaster
A SPMC (Single producer multi consumer) broadcasting channel to broadcast notifications between threads
-
thread-safe
Container that allows thread safety for thread-unsafe objects
-
lock_cell
A custom locking cell type written in Rust
-
tasque
thread pool library
-
sea-streamer-stdio
🌊 SeaStreamer Standard I/O Backend
-
async-handle
A reference-counted async RwLock
-
infinitree-macros
Embedded, encrypted database with tiered cache
-
optimistic-cell
lock-like structure for low-overhead optimistic concurrency
-
RobotS
Actor framework
-
jobsteal
A work-stealing fork-join threadpool written in Rust
-
tange
Scalable Task-based Parallelism Framework
-
double-checked-cell
A thread-safe lazily initialized cell using double-checked locking
-
pour
Optionally consed radix tries for fast set operations
-
cooper
in-process, async Actor library for Rust
-
static_locks
The
parking_lot
locks but usable in statics and const fn -
futex-queue
An efficient MPSC queue with timer capability based on Linux futex. Suitable for real-time applications.
-
tinypool
thread pool implementation in Rust
-
hv-atom
Convenient abstractions for atomic operations on smart pointer/reference types, based on the
atom
crate -
funfsm
An FSM library where the states are functions
-
unknownrori-simple-thread-pool
A lighweight thread pool for networking and other stuff
-
actress
actor library for Rust
-
moite_moite
Split a value in two owned parts
-
datacake-eventual-consistency
Eventually consistent state replication as a library (consensus, RPC and conflict resolution) for building your own eventually consistent databases
-
tpx
Task scheduler
-
monotone-cli
Monotonic counter cli implemented on top of AWS DynamoDB
-
ringtail
Efficient ring buffer for byte buffers, FIFO queues, and SPSC channels
-
lagoon
A thread pool crate with an array of features
-
boomerang_builder
The Reactor assembly API for Boomerang
-
faa_array_queue
Fetch-And-Add Array Queue implementation for Rust
-
kabuki
Name reservation
-
jxl-threadpool
Internal crate of jxl-oxide to abstract over thread pool implementation
-
deterministic
building blocks for testable systems
-
open-coroutine-hooks
The syscall hook for open-coroutine
-
yaar-lock
Fast, no_std synchronization primitives
-
adirector
asynchronous tokio task spawner with a limited size
-
kompact-component-derive
A derive macro for Kompact component definitions
-
lockness
TODO
-
open-coroutine-core
The open-coroutine is a simple, efficient and generic coroutine library
-
threadpool-simple
Threadpool for working with many tasks easily
-
smol-axum
Integrations between
smol
andaxum
-
fs-mel
Mélodium core filesystem interaction library
-
once_map
Single assignment and lazy maps
-
agner
An actor toolkit inspired by Erlang/OTP
-
batch_queue
A single-producer single-consumer Rust queue with smart batching
-
hel-thread-pool
sync thread pool
-
fibril_verifier
Verifies behavior for distributed systems implemented with the Fibril library
-
provenant
A version of Arc that can free memory while weak pointers exist by probabilistically tracking provenace
-
hj_thread_pool
thread pool implementation in Rust
-
open-coroutine-macros
The proc macros for open-coroutine
-
worker-pool
handle a set of worker threads, which need to communicate back their result to the main thread
-
acril
A kitchen-sink actor framework
-
swctx
One-shot channel with some special semantics
-
actors
actor-like concurrency for Rust
-
jobpool
lightweight threadpool implementation
-
pmpmc
A priority multi producer multi consumer channel
-
meslin
Ergonomic messaging for Rust
-
ach-array
Atomic Channel
-
rustpool
A data and thread pool library for Rust
-
channel_pipes
Perform operations on broadcast queues
-
tange-collection
Dataflow computation
-
portable-atomic
Portable atomic types including support for 128-bit atomics, atomic float, etc
-
crtq
A MPMC wait-free queue
-
rustc-rayon-core
Core APIs for Rayon - fork for rustc
-
melodium-repository
Repository managment crate for Mélodium, with dependency resolution and retrieval
-
kompact-actor-derive
A derive macro for Kompact Actors
-
mailbox_processor_rs
Actor abstraction inspired by the FSharp MailboxProcessor
-
tyractorsaur
Typed Actor System
-
sea-streamer-kafka
🌊 SeaStreamer Kafka / Redpanda Backend