-
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
-
async-lock
Async synchronization primitives
-
async-channel
Async multi-producer multi-consumer channel
-
flume
A blazingly fast multi-producer channel
-
ringbuf
Lock-free SPSC FIFO ring buffer with direct access to inner data
-
crossbeam
Tools for concurrent programming
-
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
-
triomphe
A fork of std::sync::Arc with some extra functionality and without weak references (originally servo_arc)
-
neon
A safe abstraction layer for Node.js
-
loom
Permutation testing for concurrent code
-
jobserver
GNU Make jobserver for Rust
-
thread-priority
managing threads priority and schedule policies
-
sync_wrapper
enlisting the compiler's help in proving the absence of concurrency
-
arcstr
A better reference-counted string type, with zero-cost (allocation-free) support for string literals, and reference counted substrings
-
kanal
The fast sync and async channel that Rust deserves
-
corosensei
A fast and safe implementation of stackful coroutines
-
sled
Lightweight high-performance pure-rust transactional embedded database
-
mpi
Message Passing Interface bindings for Rust
-
parking
Thread parking and unparking
-
state
safe and effortless global and thread-local state management
-
rtrb
A realtime-safe single-producer single-consumer ring buffer
-
atomic_float
Floating point types which can be safely shared between threads
-
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.
-
stateright
A model checker for implementing distributed systems
-
ipc-channel
A multiprocess drop-in replacement for Rust channels
-
may
Rust Stackful Coroutine Library
-
bus
A lock-free, bounded, single-producer, multi-consumer, broadcast channel
-
local-channel
A non-threadsafe multi-producer, single-consumer, futures-aware, FIFO queue
-
flurry
Rust port of Java's ConcurrentHashMap
-
rayon-cond
Experimental iterator wrapper that is conditionally parallel or serial
-
hwlocality
Idiomatic Rust bindings for the hwloc hardware locality library
-
boxcar
A concurrent, append-only vector
-
try-lock
A lightweight atomic lock
-
throttle-server
Provide semaphores for distributed systems via an http interface
-
scheduled-thread-pool
A scheduled thread pool
-
leaky-bucket
A token-based rate limiter based on the leaky bucket algorithm
-
radium
Portable interfaces for maybe-atomic types
-
shuttle
testing concurrent Rust code
-
concurrent-queue
Concurrent multi-producer multi-consumer queue
-
futures-intrusive
Futures based on intrusive data structures - for std and no-std environments
-
ratelimit
ratelimiter that can be shared between threads
-
cargo-green
Cargo plugin and $RUSTC_WRAPPER to sandbox & cache cargo builds and execute jobs remotely
-
thread-id
Get a unique thread ID
-
jod-thread
std::thread which joins on drop by default
-
gst-plugin-threadshare
GStreamer Threadshare Plugin
-
tachyonix
A very fast asynchronous, multi-producer, single-consumer bounded channel
-
amity
Concurrency algorithms
-
mpstthree
implementing Multiparty Session Types for 2 or more participants
-
rustc-rayon
work-stealing parallelism for Rust - fork for rustc
-
executors
A collection of high-performance task executors
-
once_map
Single assignment and lazy maps
-
typedmap
A hash map (dash map). A type of value is defined by trait implemented on key type
-
guardian
owned mutex guards for refcounted mutexes
-
surrealkv
A low-level, versioned, embedded, ACID-compliant, key-value database for Rust
-
orx-concurrent-vec
A thread-safe, efficient and lock-free vector allowing concurrent grow, read and update operations
-
pend
do now, wait later – tiny job runner
-
inline-array
efficient immutable inlinable byte array
-
async-condvar-fair
Condition variables for async Rust
-
process_control
Ergonomically run processes with limits
-
atomig
Generic, convenient and lock-free
std
atomics viaAtomic<T>
. Can be used with many primitive types (including floats) and with custom types. -
sdd
Scalable lock-free delayed memory reclaimer
-
desync
A hassle-free data type for asynchronous programming
-
chili
low-overhead parallelization library
-
turnkeeper
An asynchronous, recurring job scheduler for Tokio with support for CRON, interval, and weekday/time schedules, plus retries, cancellation, and observability
-
paralight
A lightweight parallelism library for indexed structures
-
iroh-gossip
gossip messages over broadcast trees
-
crossbeam-channel
Multi-producer multi-consumer channels for message passing
-
ppl
A structured parallel programming library for Rust
-
idr-ebr
An efficient concurrent ID to object resolver
-
rclite
small, fast, and memory-friendly reference counting compatible with Arc and Rc APIs
-
mco
Rust Coroutine Library like go
-
uid
creation of unique IDs
-
clashmap
Sharded hashmap suitable for fast concurrent access
-
fault-injection
fault injection, concurrency delay injection, and error source annotation
-
safe-lock
A lock struct with a
const fn
constructor and nounsafe
- ARCHIVED -
mutex
An abstraction over closure-based mutexes
-
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)
-
waker-fn
Convert closures into wakers
-
evolution
Efficiently evolve your old fixed-length data files into modern file formats
-
open-coroutine
efficient and generic stackfull-coroutine library
-
atomic-time
AtomicDuration
,AtomicOptionDuration
,AtomicSystemTime
,AtomicOptionSystemTime
,AtomicInstant
andAtomicOptionInstant
for Rust -
happylock
Free deadlock prevention
-
runnel
the pluggable io stream. now support: stdio, string io, in memory pipe
-
chorus
interacting with multiple Spacebar-compatible Instances at once
-
grip-grab
A faster, more lightweight ripgrep alternative
-
workerpool
A thread pool for running a number of jobs on a fixed set of stateful worker threads
-
sea-streamer
🌊 The stream processing toolkit for Rust
-
synchronized
convenient macro for synchronizing code in multithreading
-
pausable_clock
A source of time information that can be paused and resumed
-
nuclei
Proactive IO & runtime system
-
st3
A very fast lock-free, bounded, work-stealing LIFO queue
-
rtactor
An Actor framework specially designed for Real-Time constrained use cases
-
botcore
Production-grade asynchronous bot engine with enterprise observability features
-
mcslock
Mellor-Crummey and Scott contention-free lock for mutual exclusion, referred to as MCS lock
-
seize
Fast, efficient, and predictable memory reclamation for concurrent data structures
-
parallel-sh
Execute commands in parallel
-
deqp-runner
A VK-GL-CTS/dEQP wrapper program to parallelize it across CPUs and report results against a baseline
-
wd_tools
tools for rust
-
rtthost
RTT (Real-Time Transfer) client
-
rearch
Re-imagined approach to application design and architecture
-
shred
Dispatches systems in parallel which need read access to some resources, and write access to others
-
messaging_thread_pool
aiding the creation of typed thread pool of objects that is communicated with via channels
-
ordered-channel
A channel that always receives messages in the correct order, even if they were sent out of order
-
fieldx
Procedural macro for constructing structs with lazily initialized fields, builder pattern, and serde support with a focus on declarative syntax
-
sync_file
Files that can be read concurrently
-
par-core
Switchable parallel execution core
-
yazi-scheduler
Yazi task scheduler
-
arrayfire
high performance software library for parallel computing with an easy-to-use API. Its array based function set makes parallel programming simple. ArrayFire's multiple backends (CUDA…
-
io-reactor
Concurrent I/O resource management using reactor pattern
-
rcu_cell
a lockless rcu cell implementation
-
flo_scene
Entity-messaging system for composing large programs from small programs
-
rs-event-emitter
simulate promise implementation for rust
-
threadbound
Make any value Sync but only available on its original thread
-
onering
High throughput synchronous queue
-
recloser
A concurrent circuit breaker implemented with ring buffers
-
infinitree-backends
Embedded, encrypted database with tiered cache -- backends
-
crossbeam-utils
concurrent programming
-
oqueue
Non-interleaving multithreaded output queue
-
synchronoise
Synchronization primitives that build upon the standard library
-
mea
A runtime-agnostic library providing essential synchronization primitives for asynchronous Rust programming
-
television
A cross-platform, fast and extensible general purpose fuzzy finder TUI
-
gabriel2
Indeed, an actor library based on Tokio, written in Rust
-
loole
A safe async/sync multi-producer, multi-consumer channel
-
rsevents
Manual and auto reset events for signaling threads and writing new synchronization primitives like semaphores
-
orx-concurrent-iter
A thread-safe and ergonomic concurrent iterator trait and efficient lock-free implementations
-
atomptr
A safe copy-on-write wrapper around
AtomicPtr
with some extra tricks -
trauma
Simplify and prettify HTTP downloads
-
paradis
Parallel processing with disjoint indices
-
pumps
Eager streams for Rust
-
magnetic
Low-latency lock-free queues
-
leapfrog
A fast, lock-free concurrent hash map
-
pueue
A cli tool for managing long running shell commands
-
callysto
Stream processing framework
-
ballista-scheduler
Ballista Distributed Compute - Scheduler
-
batch-aint-one
I got 99 problems, but a batch ain't one
-
nbio
Non-Blocking I/O
-
atom_box
A safe idiomatic Rust implementation of Atomic Box using hazard pointers
-
omango
Concurrency collections
-
atomic-file-install
For atomically installing a file or a symlink
-
thingvellir
a concurrent, shared-nothing abstraction that manages an assembly of things
-
locktick
Automated lock accounting & profiling
-
razel
a command executor with caching for data processing pipelines
-
elysees
A fork of triomphe, now with more pointer trickery
-
renoir
Reactive Network of Operators In Rust
-
krecik
Asynchronous, parallel external service checker (and reporter), using industry standard libraries: Curl, ngHTTP2 and OpenSSL
-
rtic-sync
Synchronization primitives for asynchronous contexts
-
sanitizers
Interfaces and FFI bindings for the sanitizers interfaces
-
piz
piz (a Parallel Implementation of Zip) is a ZIP archive reader designed to concurrently decompress files using a simple API
-
melodium
Flow-oriented language & tool, focusing on treatments applied on data, allowing high scalability and massive parallelization safely
-
concurrent_arena
u32 concurrent insertion/removal arena that returns ArenaArc
-
atomic_once_cell
Thread-safe and lock-free OnceCell and Lazy
-
d-engine
A lightweight and strongly consistent Raft consensus engine written in Rust. It is a base to build reliable and scalable distributed systems.
-
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
-
openfga-client
Type-safe client SDK for OpenFGA with optional Authorization Model management and Authentication (Bearer or Client Credentials)
-
sharded_mutex
No per-object memory overhead locks. Pseudo atomic ops for Copy/PartialEq types.
-
pi_arr
lock-free & auto-expansion array
-
myriam
Actor model implementation for local and remote actors
-
progress-token
tracking progress of long-running tasks
-
spinning_top
spinlock crate based on the abstractions provided by
lock_api
-
atomic-arena
Generational arena that allows reserving keys from other threads
-
atomic
Generic Atomic<T> wrapper type
-
async-local
For using thread locals within an async context across await points
-
tc-transact
Traits and locking utilities for a TinyChain transaction
-
speare
actor-like thin abstraction over tokio::task and flume channels
-
per-thread-mutex
Synchronization lock designed for wrapping thread-unsafe C libraries
-
atomic-take
Atomically take a value out of a container once
-
threadpools
Efficient, configurable, zero-dependency thread pool implementations. Flexible and usable for a wide variety of applications.
-
siafu
Ergonomic job scheduling library for Rust
-
no_deadlocks
A Runtime Deadlock Debugger
-
concurrent-map
a lock-free linearizable B+ tree
-
nexus-acto-rs
Actors
-
aarc
Atomically updatable variants of Arc and Weak for lock-free concurrency
-
pbrt-r3
pbrt-v3
-
ostd
Rust OS framework that facilitates the development of and innovation in OS kernels
-
choir
Task Orchestration Framework
-
splaycast
Stream-specific broadcast channel
-
mirai-annotations
Macros that provide source code annotations for MIRAI
-
transactional
optimistic lock-free confirmation-based transactional model for Rust
-
liner_broker
Redis based message serverless broker
-
wb_async_utils
working with async code
-
scx_bpfland
A vruntime-based sched_ext scheduler that prioritizes interactive workloads. https://github.com/sched-ext/scx/tree/main
-
duchess
Silky smooth Java-Rust interop
-
range-lock
Range lock for std::vec::Vec
-
channel
Rust advanced queue library
-
mintex
minimal mutex
-
ibuf
A memory buffer pool implementation
-
test_cpu_parallel
Generate CPU- or memory-intensive workloads for benchmarking
-
arccstr
Thread-safe, reference-counted null-terminated immutable strings
-
iterator_ilp
Iterator extensions for instruction-parallel reductions
-
sync42
synchronization tools
-
protoflow
implements flow-based programming (FBP) for Rust using Protocol Buffers messages
-
stupid_utils
that provides some simple and maybe stupid or useful tools
-
fdup
find duplicate files recursively and in parallel
-
sovran-arc
Memory management swift-isms brought to Rust
-
gasket
Staged Event-Driven Architecture (SEDA) framework
-
atomic-wait
Cross-platform atomic wait and wake (aka futex) functionality
-
acts
a fast, tiny, extensiable workflow engine
-
schedules
A lightweight Rust library for managing operations across multiple time scales
-
rc_event_queue
VecDeque-like fast, unbounded, FIFO, concurent read-lock-free message queue
-
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
-
esl01-indexedlog
Append-only on-disk storage with integrity checks and indexing support
-
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
-
bcast
Low latency broadcast (SPMC) buffer designed to work with shared memory
-
atomic-shim
Atomic types for unsupported platforms
-
pubsub-bus
Thread-safe one-to-many publish-subscribe event system. Simple and easy to use. It just works (hopefully).
-
acts-next
a fast, tiny, extensiable workflow engine
-
rcron
cron job scheduling for rust
-
keepcalm
shared types for multi-threaded programs
-
quartz
Port of the original Java Quartz Scheduler to Rust
-
balter
A load/stress testing framework
-
irox-threading
Blocking and Asynchronous Threading Tools
-
testbench
Testing and benchmarking tools for concurrent Rust code
-
resilient-rs
fault tolerance, including retry strategies, backoff mechanisms, and failure handling
-
atomic-lend-cell
lending immutable references across threads with explicit owner-borrower semantics, offering both atomic reference counting and lightweight flag-based implementations
-
namaste
-
ptr_cell
Thread-safe cell based on atomic pointers
-
lock-free-static
Lock-free static variables
-
readlock
A weird alternative to Arc<RwLock<T>>
-
simd-itertools
SIMD-accelerated alternatives for common operations like contains, max, find etc
-
par_slice
Slices that may be accessed from multiple threads with different levels of safety
-
atomx
Thread safe data structures based on atomic data types
-
rs-store
Redux Store for Rust
-
narust-158
reimplementation of OpenNARS 1.5.8
-
virtual-buffer
A cross-platform library for dealing with buffers backed by raw virtual memory
-
clave
Midi click-track generator
-
node-replication
An operation-log based approach that transform single-threaded data structures into concurrent, replicated structures
-
portable_atomic_enum
An attribute to create an portable atomic wrapper around a C-style enum
-
cfavml
CF's Accelerated Vector Math Library providing SIMD optimzied routines for vector operations
-
rt
A real-time operating system capable of full preemption
-
que
A high performance channel with optional backpressure, interprocess capability, and a multiconsumer mode
-
pi_append_vec
Only supports append vectors, lock free
-
swap-buffer-queue
A buffering MPSC queue
-
rust-releases
Find, index and obtain all officially available Rust releases
-
affinitypool
running blocking jobs on a dedicated thread pool with CPU core affinity
-
round_mult
A tiny library to round a number up or down to a multiplier
-
lockmap
A high-performance, thread-safe HashMap implementation for Rust that provides fine-grained locking at the key level
-
chalamet_pir
Stateful, Single-Server Private Information Retrieval for Key-Value Databases
-
lockfree
concurrent data structures and a solution to the ABA problem as an alternative of hazard pointers
-
lever
Pillars for Transactional Systems and Data Grids
-
swimos_introspection
SwimOS Agent Introspection
-
crosstermion
crossterm
, without ties totermion
-
semka
Semaphore implementation
-
utils-atomics
Various atomic utils
-
lock-hierarchy
Prevent dead locks by enforcing lock hierarchies
-
kcr_execution_furiko_io
Kubernetes Custom Resource Bindings
-
pawawwewism
a wewy sewious wibwawy fow stwuctuwed concuwwency, i pwomise :3
-
lock_api
Wrappers to create fully-featured Mutex and RwLock types. Compatible with no_std.
-
linked
Create families of linked objects that can collaborate across threads while being internally single-threaded
-
may_actor
Actor library based on MAY
-
rt-history
An RT-safe history log with error checking
-
latches
A downward counter (CountDownLatch) which can be used to synchronize threads or coordinate tasks
-
io-pipe
A fast and thread-safe library for creating multi-writer and single-reader pipelines in Rust
-
tlrepo
Thread-local git2::Repository, shareable across threads
-
svix-ksuid
A pure Rust and fully tested KSUID implementation
-
walle-core
OneBot lib in Rust
-
sigq
Queue that signals waiting consumers about node availability
-
rds_lock
asynchronous redis distributed read-write lock implementation based on tokio and redis-rs
-
opentalk-janus-client
A janus client implementation for use in OpenTalk
-
rocketmq-client-v4
rocket mq rust client for remote protocol. works on rocket mq V4
-
cubecl-hip-sys
Rust bindings for AMD ROCm HIP runtime libraries used by CubeCL
-
timely-master
A low-latency data-parallel dataflow system in Rust
-
ibag
A thread-safe, immutable bag for holding any value
-
orchestrator_lock
A Mutex whose access order is managed by a separate thread
-
someday
Lock-free MVCC primitive
-
sync-arena
thread-safe arena allocator
-
infinitree
Embedded, encrypted database with tiered cache
-
rusturnate
A sync or async mutex, with or without timeouts
-
active_standby
A concurrency primitive for high concurrency reads
-
nexus-actor-utils-rs
Nexus Actor
-
debugrs
logger that mimics the npm debug module
-
rex-sm
Hierarchical state machine
-
discord_client_rest
Undetected discord client rest API reimplementation
-
timeslice
periodic time slice scheduler
-
tether-agent
Standardised use of MQTT and MessagePack for inter-process communication
-
rsvow
A Rust-like implementation of JavaScript's Promise mechanism
-
timely_communication
Communication layer for timely dataflow
-
atomic-counter
Atomic (thread-safe) counters for Rust
-
treiber_stack
A lockless, thread-safe, atomic linked-list
-
gst-plugin-inter
GStreamer Inter Plugin
-
tonari-actor
A minimalist actor framework aiming for high performance and simplicity
-
actm
Tiny async actors framework for rust
-
simple_coro
(ab)using async/await to write simple state-machine based coroutines
-
wl-client
Safe client-side libwayland wrapper
-
hab-rs-api-client
Bindings for openHAB REST API
-
kube-leader-election
Leader election implementations for Kubernetes workloads
-
disruptor-rs
A high-performance ring buffer implementation of the LMAX Disruptor pattern
-
rearch-tokio
Re-imagined approach to application design and architecture
-
blueprint-producers-extra
Additional job call producers for the Blueprint SDK
-
lmml
LMML Music Macro Language
-
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 -
command_history
managing command history in Rust applications
-
thread_io
performing I/O in background thread
-
visa-device-handler
handle NI-VISA connections and simplify its use
-
direct_ring_buffer
A high-performance, lock-free ring buffer for single-producer, single-consumer scenarios
-
daemonbit
Cross-platform daemon lifecycle primitives
-
flag-bearer-mutex
Generic async semaphores
-
write_atomic
Write to files atomically
-
constellation-rs
Constellation is a framework for Rust (nightly) that aides in the writing, debugging and deployment of distributed programs
-
process_anywhere
Tools for running computer processes locally and remotely via SSH
-
antidote
Poison-free versions of the standard library Mutex and RwLock types
-
parallel_worker
A parallel worker implementation in Rust. Allows to start tasks in parallel and receive the results blocking or non-blocking.
-
EMCompute
fast , simple and cross-platform parallel computing library
-
dapt
serializing and unseralizing unstructured data
-
txn_lock
support transactional versioning
-
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.
-
pargraph
Operator based parallel graph processing
-
crossbeam-queue
Concurrent queues
-
mpsc_requests
mpsc channels but with a response
-
rust-lockless-slotmap
A (mostly) lockless slotmap implementation in Rust
-
orx-parallel
High performance, configurable and expressive parallel computation library
-
async_once
async once tool for lazy_static
-
papaya
A fast and ergonomic concurrent hash-table for read-heavy workloads
-
k-lock
A fast mutex for short critical sections
-
pacwrap-agent
Executable agent for conducting containerized transactions
-
send_cells
Safe and unsafe cells implementing Send/Sync
-
congee
ART-OLC concurrent adaptive radix tree
-
mm1-node
M/M/1! Queueing, do you speak it?!
-
atomicring
AtomicRingBuffer is a constant-size almost lock-free concurrent ring buffer
-
thread_map
Types that are simple and easy-to-use alternatives to the
std::thread_local
macro -
blazingqlog
QUIC QLOG parser written in Rust
-
rust_kits
kits
-
resilient-rabbitmq-client
Easily deploy resilient RabbitMQ consumers and publishers
-
limqch
A channel built on top of limq
-
kc
Kayla's (line) counter (of code) :)
-
komora-sync
Synchronization structures for the komora db project
-
cdk-from-cfn
Turn AWS CloudFormation templates into AWS CDK applications
-
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
-
fast-steal
特别快的多线程库,支持超细颗粒度的任务窃取
-
electrologica
High performance concurrent primitives for Rust
-
nbus
A lock-free, bounded, single-producer, multi-consumer, broadcast channel
-
sync-cell-slice
Cells and slices that are accessible from multiple threads
-
jwalk-meta
Filesystem walk performed in parallel with streamed and sorted results
-
rust-pubsub
A thread-safe, in-memory publish-subscribe library for Rust with flexible subscription modes
-
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…
-
fuyu
programming language
-
rust_supervisor
An Erlang-inspired process supervision library for Rust
-
patrolilo
Job scheduler with integrated NTFY notifications
-
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…
-
crossbeam-skiplist-mvcc
Support MVCC (Multiple Version Concurrent Control) for
crossbeam-skiplist
-
scx_loader
DBUS on-demand loader of sched-ext schedulers
-
sovran-state
state management for Rust
-
tc-scalar
TinyChain's scalar value enum, including concurrently-resolvable op definitions and references
-
xstm
A Rust-implemented Software Transactional Memory (STM) library using TL2 (Transactional Locking II) algorithm
-
asyncgit
allow using git2 in a asynchronous context
-
thermal_hydraulics_rs
A Thermal Hydraulics Library with some useful traits,enums and functions for heat transfer and fluid mechanics
-
openmp-reducer
OpenMP-style reducers
-
rrddmma
RDMA
-
atomicbox
Safe atomic pointers to boxed data
-
fluxion
actor framework written in rust and designed for distributed systems
-
monch
Inspired by nom, but specifically for strings
-
atomic-server
Create, share and model Atomic Data with this graph database server. Run atomic-server without any arguments to start the server. Use --help to learn about the options.
-
tensr
A high-performance, cross-platform, multi-backend tensor/array library for Rust
-
alopt
providing efficient synchronization primitives that integrate Option into their design
-
shipyard_scenegraph
Scenegraph for Entity Component System
-
concurrent-slotmap
A lock-free concurrent slotmap
-
aranya-util
needed by other Aranya crates
-
atomic_enum
An attribute to create an atomic wrapper around a C-style enum
-
signals2
A thread-safe signal/slot library inspired by boost::signals2
-
orx-concurrent-bag
An efficient, convenient and lightweight grow-only concurrent data structure allowing high performance concurrent collection
-
fast-async-mutex
lib which provide asynchronous locking mechanisms (Mutex, RwLock, OrderedMutex and OrderedRwLock)
-
bus_queue
Lock-free Bounded non-Blocking Pub-Sub Queue
-
api-rate-limiter
rate limiter for Rust APIs
-
conquer-once
Synchronization primitives for lazy and one-time initialization
-
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
-
drcp-format
Parse and write DRCP and literal definition files
-
rust_abf
reading data from Axon Binary Format (ABF) files
-
sync-unsafe-cell
A backport of the SyncUnsafeCell standard library type for use in older Rust versions
-
atomic-destructor
Atomic destructor for multi-threaded env
-
parallel_operations
perform binary operations in parallel using threads
-
par
Session types, as an implementation of linear logic with MIX
-
kueue
A robust, user-level, work-stealing, distributed task scheduler
-
parseq
Parallel sequential iterator
-
with_daemon
An async client-daemon abstraction framework
-
unlock
Instrumented synchronization primitives helping you to unlock performance issues
-
rtic-time
Basic definitions and utilities that can be used to keep track of time
-
asknothingx2-eventsub
Twitch eventsub
-
par-iter-sync
Parallel Iterator With Sequential Output
-
arcu
An Rcu implementation using an Arc to keep the read critical section short and handle cleanup
-
atomic_pincell
Threadsafe pinnable RefCell
-
television-fuzzy
The revolution will be televised
-
sparkles
Capture execution flow of your Rust application with CPU cycle precision!
-
crc32c-cli
CLI wrapper for the crc32c crate
-
relay_channel
A single-producer, single-consumer channel where the sender waits for the receiver to receive the message before returning
-
umpx
Collection of ump extensions
-
global_counter
Global, thread-safe counters
-
streameroo
Compilation of mini-frameworks & utilities for data-streaming applications
-
orama-js-pool
Create a pool of JavaScript engines to invoke JavaScript code concurrently
-
blocking-threadpool
A thread pool for running a number of jobs on a fixed set of worker threads
-
circ
Efficient referenced counted pointers for non-blocking concurrency
-
clhlock
Craig and, indenpendently, Magnussen, Landin, and Hagersten queue lock for mutual exclusion, referred to as CLH lock
-
make87
Rust SDK for make87 platform
-
pyth-lazer-publisher-sdk
Pyth Lazer Publisher SDK types
-
veneer
A very thin std-like library that doesn't depend on libc
-
tracing-mutex
Ensure deadlock-free mutexes by allocating in order, or else
-
ipc-rpc
A wrapper over servo/ipc-channel which provides many high level features
-
arrayfire_fork
ArrayFire is a high performance software library for parallel computing with an easy-to-use API. Its array based function set makes parallel programming simple. ArrayFire's multiple backends (CUDA…
-
gettid
Helper to get an integer ID for the current thread
-
cachemap2
A concurrent insert-only hashmap for caching values
-
kontroli
Type checking for the lambda-Pi calculus modulo rewriting
-
event-trigger-action-system
A system that triggers actions based on events with user-programmable triggers
-
ollie
An abstraction layer on top of lapin, to align with traditional HTTP API routing
-
permit
A struct for cancelling operations
-
bztree
BzTree implementation for Rust
-
td_rthreadpool
thread wrapper for Rust
-
nexus-actor-remote-rs
Remote library for Nexus Actor
-
vlock
A fast and scalable multi-version shared state lock with wait-free read access
-
freezebox
deref'able lazy-initialized container
-
topograph
A miniscule thread pool and toposort scheduler
-
mutex_trait2
Generic mutex trait
-
threadcell
A cell whose value can only be accessed by a owning thread
-
watchable
RwLock-like type that is compatible with both multi-threaded and async code
-
peace-lock
A zero-cost abstraction lock that helps check contention free algorithms
-
redlock
distributed locking mechanism built on top of Redis
-
adaptive-barrier
Barrier with adaptable number of thread subsciptions
-
local-sync
Non-threadsafe data structure for async usage
-
mq
Message Queue
-
fetchchromium
fetch Chromium builds rapidly
-
devproxy
A local development proxy for testing different network conditions
-
snowdon
A lightweight thread-safe snowflake ID implementation for Rust
-
x32_osc_state
X32 State Tracker via Open Sound Control
-
flo_scene_guest
no_std implementation of the guest protocol for flo_scene for smaller wasm guests
-
lfchring
Concurrent, lock-free implementation of a consistent hashing ring data structure, supporting virtual nodes and keeping track of replication
-
usync
fast, drop-in, synchronization primitives
-
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
-
smart_channel
channel subscription system
-
throttle-client
Client for Throttle. Throttle is an http semaphore service, providing semaphores for distributed systems.
-
ringbuf-blocking
Blocking version of ringbuf
-
rw-cell
Write data to cell from anything place your application without copy, lock and reading in one place
-
fastpool
This crates implements a fast object pool for Async Rust
-
session_types
session types in Rust
-
multipool
A configurable thread pool with optional work-stealing support and task priority scheduling
-
crossbeam-deque
Concurrent work-stealing deque
-
halt
functionality for pausing, stopping, and resuming iterators, readers, and writers
-
work-queue
A concurrent work-stealing queue for building schedulers
-
incr
fast and self-contained data structures for checking whether a new value is greater than the previous maximum
-
async-time-mock-core
Mockable time for use in async runtimes (core package)
-
screeps-async
Tick-aware Async runtime for Screeps
-
simple-semaphore
🔐 A lightweight implementation of a Semaphore in Rust
-
replay-channel
A broadcast channel where new receivers replay all past messages before receiving new ones
-
bastion
Fault-tolerant Runtime for Rust applications
-
miracle
Generic pub/sub resource server for Project Lighthouse models
-
spools
Content scraping library for Instagram's Threads
-
sea-streamer-socket
🌊 SeaStreamer backend-agnostic Socket API
-
zallocator
Amortizes the cost of small allocations by allocating memory in bigger chunks
-
ebr
epoch-based reclamation with low cacheline ping-pong
-
stele
An atomic Vec-like structure with no copying on allocation
-
msr-plugin
Industrial Automation Toolbox - Plugin foundation
-
slog-atomic
Atomic run-time controllable drain for slog-rs
-
mailboxxy
micro actor library for rust
-
agave-scheduler-bindings
Agave Scheduler Bindings
-
spindle_rs
A distributed locking crate built on Cloud Spanner and TrueTime
-
laad
parsing information from a TBS battery monitor, such as the Battery Monitor Expert Modular
-
async-mutex
Async mutex
-
logging-subscriber
logging subscriber which can be silenced
-
skedgy
asynchronous job scheduler
-
nest-guard
working with nested guard-type APIs
-
lvm-sys2
LVM FFI bindings
-
pinned-mutex
Mutex wrappers with structural pinning
-
global-channel
global channels
-
watch
A synchronous message passing channel that only retains the most recent value
-
uflow
ordered, mixed-reliability, and congestion-controlled data transfer over UDP
-
pi_share
rc, arc, lock, atomic
-
employees
A small runtime that hides all the boilerplate when using threads
-
cpu-utils
Contains utility functions to work with CPU
-
congestion-limiter
Dynamic congestion-based concurrency limits for controlling backpressure
-
scx_chaos
general purpose sched_ext scheduler designed to amplify race conditions
-
single_value_channel
Concurrent single-value update and receive channel
-
lockpool
offers a pool of locks where individual locks can be locked/unlocked by key
-
rgraph
A task graph library
-
ckbes
CKB Easy Script is a framework for developing ckb contracts
-
libc-nnsdk
Rust bindings for the parts of libc exposed by nnsdk, intended to be a in-place replacement for standard Rust libc bindings
-
norpc
Framework for in-process microservices
-
poll-channel
Poll on channel
-
sentinel-core
The flow sentinel of your microservices
-
logical-expressions
working with logical expressions
-
miyabi_scheduler
Thread pool scheduler with extra specific abilities
-
mbarc-map
Minimally-blocking, Atomic Reference Counted Map
-
kvbench
A key-value store benchmark framework with customizable workloads
-
lakka
actors with macros
-
ellie_vm
Ellie VM for running Ellie ByteCode
-
disrustor
This project is a port of the LMAX Disruptor to Rust
-
mu_uefi_tpl_mutex
Task Priority Level (TPL) mutual exclusion support
-
rspack_plugin_ensure_chunk_conditions
rspack ensure chunk conditions plugin
-
acto
light-weight Actor library for Rust
-
atomic-queue
bounded lock-free queue for use in Audio applications, ported from https://github.com/max0x7ba/atomic_queue
-
crosstalk
An extremely lightweight, topic-based, cross-thread, in-memory communication library
-
seqlock
A reader-writer lock that provides extremely fast read access without starving writers
-
stakker_log
Logging support for Stakker
-
approximate
Scalable Approximate Counters
-
mpsc
mpsc channel
-
platoon
An experimental mini async runtime
-
folklore
A lock-free concurrent hash map
-
mpvipc
A small library which provides bindings to control existing mpv instances through sockets
-
ngtq
A trait-based abstraction layer for task queues with ID and category support
-
diplomatic-bag
A wrapper type that allows you to send
!Send
types to different threads -
zawgl-client
Zawgl Graph Database Client
-
fork-map
running operations in a child process spawned by
fork()
-
open-coroutine-hook
The syscall hook for open-coroutine
-
invocation-counter
Datastructure to answer to: how many times a function has been called in the last X minutes?
-
blackhole
...to throw your threads into
-
goko
A lock-free, eventually consistent, concurrent covertree
-
lilac
Static site generator-esque tool for adding include statements to HTML
-
channelmap
A DashMap wrapper over Tokio channels
-
thread_local_collect
Supports the collection and aggregation of thread-local data across threads
-
kubelet
A Kubernetes kubelet implementation in Rust
-
handoff
An unbuffered, asynchronous, single-producer/single-consumer channel
-
mpmc-async
A multi-producer, multi-consumer async channel with reservations
-
msgpass
Thin wrapper to a Message Passing Interface (MPI)
-
cron_tab
A cron job library for Rust
-
swimos_sync
SwimOS Synchronization Channels
-
mwcas
Multi-word CAS primitive
-
critical-once-cell
Thread-safe OnceCell and Lazy backed by critical section
-
mop
Flexible and modular single or multi-objective solver for contiguous and discrete problems
-
spring-stream
Integrate sea-streamer with spring-rs
-
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…
-
may_queue
May's internal queue library
-
deque
A (mostly) lock-free concurrent work-stealing deque
-
bmrng
async MPSC request-response channel for Tokio
-
whisk
fast lockless async channels
-
rocketmq
Rust client for Apache RocketMQ
-
rtic-syntax
The Real-Time Interrupt-driven Concurrency (RTIC) meta language
-
lock_tree
Prevent deadlocks at compile time. A standalone republication of the netstack3 lock-ordering crate, part of Google's Fuchsia OS.
-
pi_async
Based on future (MVP), a universal asynchronous runtime and tool used to provide a foundation for the outside world
-
cacheguard
A lightweight cache guard that pads atomics to prevent false sharing in concurrent Rust systems
-
fast-down
超级快的下载器核心库
-
augmented-atomics
Implements some extra types and utilities over atomics for building audio-thread / GUI synchronization
-
ruget
Alternative to wget written in Rust
-
timed-locks
Smart pointers to
tokio::sync
locks that either panic or error after a timeout -
sharded-offset-map
A map from u64 to T that can be written from multiple threads
-
batch-lock
A lock manager with batch-lock support
-
ump-ngx
Collection of ump-ng extensions
-
hopper
an unbounded mpsc with bounded memory
-
left-right
A concurrency primitive for high concurrency reads over a single-writer data structure
-
lock_pool
Robust, efficient, high performance, asynchronous object pooling
-
lucchetto
easily call a rust function without holding the GVL lock
-
rusty_junctions
Join Pattern implementation in Rust
-
either-slot
An atomic slot whose senders can either place their value into the slot, or retrive all the data from the slot
-
pinboard
A lock-free, threadsafe way to publish data, just stick it on the pinboard
-
stm
Software transactional memory. Allows composable atomic operations.
-
openrtb2
OpenRTB 2.5 FINAL
-
spinout
A thread-safe clonable and mutable smart-pointer akin to
Arc<Mutex<T>>
, using spin-lock instead of system futex -
snarc
Sendable Non-Atomically Reference Counted
-
entro-spin
Entro Spin is a 64-bit, true-random number generator algorithm
-
rucron
Job Scheduling Crate
-
crossfire
channels for async and threads
-
datacake
A batteries included framework for building fault-tolerance distributed data systems
-
easy-threadpool
A relatively simple thread pool which you can send jobs to
-
ccutils
Collection of utils from the CylonCore project
-
rust-toolchain
Types to model a Rust toolchain
-
portable-atomic-util
Synchronization primitives built with portable-atomic
-
lariv
Linked Atomic Random Insert Vector: a thread-safe, self-memory-managed vector with no guaranteed sequential insert
-
win-kernel
windows-kernel
-
twinsies
Smart pointer providing 2-way joint ownership of an object
-
protoflow-syntax
Protoflow implements flow-based programming (FBP) for Rust using Protocol Buffers messages
-
owning_ref
creating references that carry their owner with them
-
sparking-lot-core
parking on addresses
-
crb-download
CRB | Composable Runtime Blocks | Downloader
-
cond_sync
Hides the boilerplate code needed with std::sync::Condvar
-
tlid
Thread Local ID generator by predefined range without atomics/locks/random/time
-
yaambo
concurrent skip lists
-
carpet
A thread-safe, fully-parallel directed graph
-
sync_2
A little crate providing a Rust implemented Mutex and RwLock
-
threadpool-executor
A threadpool executor
-
rayon-cancel
An adapter to interrupt rayon parallel iterators
-
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!)
-
may_waiter
coroutine communication blocker
-
proglog
Thread safe progress logging
-
readfish-tools
Tools for analysing adaptive sampling data
-
thread-manager
A streamlined Rust library for efficient thread pooling and parallel job execution, designed for simplicity, flexibility, and performance
-
leaklist
concurrent, lock-free, singly-linked list
-
zkstate
Share a struct across multiple instances of an application using zookeeper
-
tagged-rendezvous
Rendezvous hashing with support for tag-based exclusions
-
napi_ext
Extends napi-rs with the ability to run local futures
-
ipmpsc
Inter-process Multiple Producer, Single Consumer Channels
-
rcu_list
a lockless concurrent list implementation
-
crossbeam-skiplist-pr1132
A concurrent skip list
-
pptr
Type-Driven Asynchronous Actor Runtime
-
simplelock
abstractions for inter-process synchronization
-
classic-sync
ReentrantLock, Semaphore and CyclicBarrier using Classic Linux Mutex systems
-
protex
(Process Mutex) concurrency in process level
-
crius
hystrix-like circuit breaker
-
forte
A low-overhead thread-pool with support for non-static async closures
-
ugly_smart_lib
jonny's ugly smart lib for Rust
-
rearch-effects
Re-imagined approach to application design and architecture
-
constellation-internal
Common components for the
constellation
framework -
ampsc
async multi-producer single-consumer channel
-
sea-streamer-fuse
Stream processing toolbox
-
discrab
Discord bot wrapper
-
flashmap
A lock-free eventually consistent concurrent hash map
-
starpu-sys
Low-level bindings to the StarPU runtime
-
nblock
Non-Blocking Runtime
-
cooptex
Deadlock free Mutexes
-
cogo
Rust Coroutine Library like go
-
unbounded-spsc
An unbounded spsc queue built from
bounded_spsc_queue
s -
rayon-scan
A parallel prefix scan function for ParallelIterator
-
aranya-daemon-api
UDS tarpc API between the Aranya client and the daemon
-
flo_stream
Pubsub and related streams for Rust futures
-
bi
-
simple-left-right
Lockfree, realtime safe and copy-free Synchronisation
-
kademlia-dht
Kademlia DHT
-
pikav
that help you send event to client with topic subscription
-
melodium-common
Common Mélodium elements and traits
-
daemonbit-test
Cross-platform daemon lifecycle primitives
-
sas
Salty-and-Sweet one-line Rust Runtime Performance Optimization Library
-
yaks
Minimalistic framework for automatic multithreading of hecs via rayon
-
hydra-dashmap
A fork of dashmap for the hydra framework
-
option-lock
mutex for Option values
-
file_locking
A lean file locking implementation for Unix and Windows
-
pipe-channel
Channel implementation based on pipes
-
bevy_gpu_compute
Empowering anyone to leverage GPU-acceleration with as little barrier-to-entry as possible
-
xloc
A fast, multi-threaded line counting utility written in Rust
-
waitcell
A cell type containing a value which may not yet be available
-
lock_ext
Extensions to std::sync::Mutex
-
little_raft
The lightest distributed consensus library. Run your own replicated state machine!
-
gpgpu
WIP GPGPU framework built on top of wgpu
-
flame
a profiling / flamegraph library
-
airlock
no_std async communication
-
mtlog-tokio
Scoped logging for tokio runtimes with support for log files
-
ns3-parallel
A Multitask Parallel Concurrent Executor for ns-3 (network simulator)
-
nyoom
A filesystem walker for floppy-disk
-
semalock
concurrently writing to files in a safe and efficient manner
-
dropout
Drop your objects out of main thread
-
rayon-wasm
work-stealing parallelism for Rust
-
evmap
A lock-free, eventually consistent, concurrent multi-value map
-
ocl-interop
Creates an OpenCL Context with OpenGL Interop enabled
-
atomiclock
A non-blocking lock that can be used in async contexts
-
thread-counter
way of efficiently keeping track of active threads and waiting for them to exit
-
with_lock
Deadlock freedom
-
db
Lightweight high-performance pure-rust transactional embedded database
-
hebo_codec
Packet codec for MQTT protocol
-
dager
create and execute a graph of nodes
-
pcp-mutex
A Priority Ceiling Protocol (PCP) mutex, based on Linux PI futex. Allows efficient and deadlock free execution.
-
fast-smr
Toward fast, wait-free, portable, and robust memory reclamation
-
vigil
liveness checking watchdog for detecting deadlocks/livelocks/starvation etc
-
ev_slotmap
A lock-free, eventually consistent, concurrent slot map
-
chute
Lockfree mpmc/spmc broadcast queue
-
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)…
-
rsevents-extra
Synchronization objects built on top of rsevents. Semaphore, countdown event, and more.
-
mth_calc
demonstrating Cargo. Contains helper method for running a process in parallel on all available processors.
-
slb
Sharded load balancing text-streaming Unix tool
-
mongo_sync
instant coding answers via the command line(just like howdoi)
-
dremoc-sync
Synchronization utilities
-
java-threadpool
这是一个跟java ThreadPoolExecutor线程池 使用方式基本相同的线程池
-
multithreading
in Rust
-
try-mutex
Fast non-blocking mutex
-
skedge
Ergonomic single-process job scheduling for Rust programs
-
tc-tensor
TinyChain's Tensor collection type
-
swapper
Swap ownership between threads
-
mogul
Agnosticly helps to manage concurrent versions of things
-
dynamic_join_array
A dynamic array that can be used to join futures for single thread async programming
-
cht
Lockfree resizeable concurrent hash table
-
sortlock
providing ordered locking
-
nexus-actor-core-rs
Core library for Nexus Actor
-
efflux
Easy MapReduce and Hadoop Streaming interfaces in Rust
-
tourniquet
Async native round-robin manager for remote services
-
omango-futex
Futex for Rust
-
threadalone
Make any value Send + Sync but only available on its original thread. Don't use on multi-threaded environments!
-
kcr_devops_kubesphere_io
Kubernetes Custom Resource Bindings
-
phazer
Two-phase commit for file creation
-
ring-channel
Bounded MPMC channel abstraction on top of a ring buffer
-
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.
-
redsync
Redlock for distributed locks with Redis
-
nysa
A bus for passing messages around between independent subsystems of an application
-
hipthread
no-std thread library based on pthread
-
contrie
Concurrent map and set
-
threadstack
A more ergonomic and more flexible form of thread local storage
-
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
-
double_decker
unbounded multi-producer multi-subscriber event bus built with crossbeam channels
-
parking_monitor
Parking-lot-flavored monitor synchronization construct
-
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.
-
striped-lock
Striped Lock for Rust
-
rayon-progress-bar
work-stealing parallelism for Rust
-
glock
Granular locking crate for Rust
-
hyaline-smr
Garbage Collector(Hyaline- Safe Memory Reclaimation) for lock free data structures
-
dag-scheduler
a scheduler of dag computation graph
-
xrm
Cross Runtime Manager
-
relaxed
Wrappers around Atomics that always use
Ordering::Relaxed
-
local_thread
A local thread management library for Rust. No more 'static functions in order to start threads!
-
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…
-
sharded-slab
A lock-free concurrent slab
-
critical-section
Cross-platform critical section
-
refcell-lock-api
A single-threaded implementation of lock_api for RefCell, to alllow abstracting between single-threaded & multi-threaded code
-
stuck
Multi-threading scheduled task facility building on cooperative stackful coroutine
-
node-workers
A pool of long-lived nodejs workers
-
more-sync
More synchronization utils
-
bustle
Benchmarking harness for concurrent key-value collections
-
raii-counter
RAII Counter
-
brutils
Some utilities for Rust
-
atomic-hyperloglog
thread-safe hyperloglog, with atomics
-
rcu_128
RCU (Read-Copy-Update) implementation for platforms supporting atomic 128-bit operations
-
crossbeam-skiplist_piedb
A concurrent skip list
-
anylock
Polymorphic Locks
-
vin
An ergonomic actor framework
-
thank
Shows info about crates used in your projects so you know who to thank for them and where to do the thanking
-
threadx-rs
Safe Rust Bindings for ThreadX using threadx-sys
-
async-datachannel
Async Wrapper for datachannel
-
static-key
static keys in Rust
-
wasm-bindgen-rayon
Adapter for using Rayon-based concurrency on the Web
-
skipchannel
skipchannels allow to communicate between threads, but always skip to the last sent value
-
cuneiform-fields
Field level [no_std] cache optimizations for Rust
-
atomiq
Convenient tool for atomics in Rust
-
peril
Fast and safe Hazard pointers for Rust
-
priomutex
A mutex where waiting threads specify a priority
-
concurrent_lru
A concurrent LRU cache
-
oxidater
A reusable LMAX Disruptor Implementation in Rust
-
hytra
Datastructure for fast multi-threaded updates
-
lockless
Composable, lock-free, allocation-light data structures
-
pipelines
constructing multi-threaded pipelines of execution
-
undead
search for dead code in your Python projects
-
smartpool
A very customizable, future-aware threadpool
-
refcapsule
Safely send references to other threads
-
ref-portals
Safely use (stack) references outside their original scope
-
todc-utils
building and testing distributed systems
-
runloop
Cancelable non-blocking polling threads (with optional timeouts)
-
os-unfair-lock
wrapper for Darwin os_unfair_lock
-
quartz_sched
Minimalistic scheduling library for Rust
-
sharded_queue
ShardedQueue is currently the fastest concurrent collection which can be used under highest concurrency and load
-
async-fifo
MPMC & oneshot channels with (a)sync API
-
isilon
rest api bindings
-
nbchan
Highly optimized non-blocking communication channels
-
sea-streamer-redis
🌊 SeaStreamer Redis Backend
-
minicoroutine
mini coroutine library in rust
-
dfmutex
Deadlock-free Mutex locks
-
managed-thread
Real fearless concurrency! Spawn threads that will be automatically destroyed when no longer needed
-
tokio-prometheus-metered-channel
Metered tokio channels with Prometheus metrics integration
-
cache-padded
Prevent false sharing by padding and aligning to the length of a cache line
-
crossbeam-skiplist
A concurrent skip list
-
ste
A single-threaded executor with some tricks up its sleeve
-
hey_listen
An event-dispatcher-collection offering async, sync, parallel, and prioritised solutions!
-
std-semaphore
A counting, blocking sempahore extracted from rust 1.7.0
-
ordered-locks
Compiletime deadlock avoidance
-
rcurs
An oxidized RCU implementation
-
para
A dataflow/pipeline parallelization framework
-
apalis-core
Core for apalis: simple, extensible multithreaded background processing for Rust
-
operator-framework
Tools and helpers used to create Kubernetes operators
-
concurrent-list
An append-only, single-writer multi-reader unrolled linked list
-
dci
DCI-Closed, a frequent closed itemset mining algorithm, implemented in Rust
-
yash-executor
single-threaded concurrent task executor
-
tcb
A middleware service for delivering messages in a causal order
-
io_partition
allowing to use just a part of a Read + Seek object
-
sea-streamer-examples
🌊 The stream processing toolkit for Rust
-
pflock
A phase-fair reader-writer lock that reduces worst-case blocking for readers. Especially useful for multiprocessor real-time systems.
-
oncemutex
A mutex providing one-time synchronized access, then safe unsynchronized access
-
concurrency-demo-benchmarks
A small utility to benchmark different approaches for building concurrent applications
-
orx-concurrent-option
ConcurrentOption is a lock-free concurrent read and write option type
-
godwit-daemon
A daemon runner for GodWit
-
event-bot
A bot for Telegram to manage time-based events
-
fslock
files as locks
-
driver_async
async backend for
btle
,bluetooth_mesh
andusbw
crates -
zonyitoo/coio
Coroutine scheduler with non-blocking I/O support
-
generic-session-types
Generic session types in Rust for async send recv channel
-
thread-owned-lock
Mutex which can only be unlocked by the owning thread
-
takecell
A cell type which value can only be taken once
-
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 -
spmc
channel
-
adiscord-types
The large list of Discord API types and Gateway types
-
ductile
A channel implementation that allows both local in-memory channels and remote TCP-based channels with the same interface
-
swap-arc
A swappable Arc
-
process-sync
Synchronization primitives for multiprocess environments
-
init_guard
A Synchronization Primitive for guarding against double initialization
-
debugit
Debug-print any value without trait bounds using specialization (Rust nightly channel)
-
threadsafe_zmq
Threadsafe zeromq
-
periodically
running tasks on a schedule
-
thfmr-protocol
Internal control protocol encoding and decoding library for the TouHou.FM Radio project
-
lock_many
Retry-based locking multiple mutexes at once
-
conqueue
multi-producer, single-consumer queue (MPSC)
-
rider
bounded executor for tokio; limit the count of tasks running 🚦
-
swimming
Dive into Efficiency with Swimming: A High-Performance, No-Nonsense Connection Pool
-
eventual
Future & Stream abstraction
-
anode
Concurrency library for Rust
-
greenie
Green threads and coroutines in stable Rust
-
flo_scene_pipe
Inter-scene and inter-process communication for flo_scene
-
pakr-fsm
Template to implement finite-state-machines
-
arc-cell
Helper for a simple Cell-like object containing Arc/Weak
-
atomicdouble
128-bit atomics for generic type
-
locker
named mutex/locker for rust-lang concurrency
-
boomerang
Deterministic Middleware for Robotics
-
job-pool
Thread Pool
-
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.
-
syncbuf
Append-only data structures with lock-free thread-safety and constant-time indexing
-
shared_channel
Multi-producer, multi-consumer FIFO queue communication primitives
-
atomic_prim_traits
Traits over primitive atomic types
-
ringbuf-basedrop
A fork of the
ringbuf
crate that uses basedrop’s Shared pointer in place of Arc -
threadgroup
Manage groups of threads as one unit, join the first one that finishes, timeout on join attempts
-
menmos-std
Menmos library containing misc. reusable utilities
-
unsync_channel
!Send/!Sync channels for Rust
-
workerpool-rs
workerpool for rust
-
embassy-sync
no-std, no-alloc synchronization primitives with async support
-
concurrent-slice
Extend slice-type types with methods for concurrent processing
-
mrsc
mpsc with requests
-
channel-sender
Channel Sender
-
fast-counter
A sharded concurrent counter
-
concurrent_tor
A comprehensive scraping runtime
-
atomic-waitgroup
A waitgroup implementation supports async with advanced features
-
deadlocker
Bringing builder pattern to defeat deadlocks
-
sdcons
geo-replicated distributed consensus algorithm: SDPaxos
-
idle
Collection of idle strategies to be used by thread(s) when they have no work to perform
-
clone-replace
Share mutable data by cloning and replacing a reference version
-
extra_atomics
Abstraction over atomic ptr. Such as AtomicBox and AtomicArc.
-
chunklist
A Chunk List is a new, concurrent, chunk-based data structure that is easily modifiable and allows for fast runtime operations
-
autoincrement
wrapper for different purposes
-
semaphore-key
control concurrent thread access by key using a shared semaphore
-
thread-lock
A wrapper that locks non-Send and non-Sync data to a specific thread
-
multithread
API for data-parallel tasks, rayon-lite
-
employer
Spawn worker threads and check on them later
-
atomic_refcell
Threadsafe RefCell
-
chashmap
Fast, concurrent hash maps with extensive API
-
lending_thread_pool
A thread pool where workers can lend their data to their tasks
-
jobsys
Lockless Work Stealing Job System
-
asc
Atomic Strong Count
-
sesh
deadlock-free session-typed communication
-
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…
-
jwalk
Filesystem walk performed in parallel with streamed and sorted results
-
shared_resources
shared resources container which is thread-safe, and lock-free
-
unit16
whp-unit16
-
shareable
Thread shareable objects using the minimal amount of synchronization
-
cpu-affinity
Cross-Platform CPU affinity
-
ngtask_queue_basic
A trait-based abstraction layer for task queues with ID and category support
-
atomiclock_async
async lock
-
funnel
data structure that makes it easy to read from multiple channels from a single source
-
scrummage
Fight over OS process prioritisation
-
protoflow-zeromq
Protoflow implements flow-based programming (FBP) for Rust using Protocol Buffers messages
-
cnr
An operation-log based approach for data replication
-
conquer-util
concurrent and lock-free programming
-
rtic-common
lib TODO
-
rtfm-syntax
The Real Time for The Masses (RTFM) meta language
-
flexible-locks
Flexible Locks
-
mpi-fork-fnsp
Message Passing Interface bindings for Rust (FORK)
-
persistent_stack
Concurrent persistent stack
-
lofi
Low Overhead Fibers
-
rtrb-basedrop
A fork of the
rtrb
crate that uses basedrop’s Shared pointer in place of Arc -
simdvec
Vectors, but with the operational speedup of SIMD!
-
geese_pool
Message-passing system for networking with Geese
-
lazy_id
A thread-safe lazily-initialized ID
-
forkjoin
A work stealing fork-join parallelism library for Rust
-
nvrtc
Bindings for NVIDIA® CUDA™ NVRTC in Rust
-
sleepfast
Sleep for very small amounts of time quickly
-
locktree
Experimental compiler-checked deadlock-freedom
-
namedlock
Namespaces for named locks
-
parallel-iterator
Parallelize any iterator with ease!
-
shardize
proc macro that generates code to create a sharded form of an existing container
-
sync-extra
Convenience functions to Mutex and RwLock
-
rxrs
Reactive Extensions for Rust
-
concurrency_traits
Traits for concurrent primitives
-
wasm-futures-executor
Executor for asynchronous task based on wasm web workers
-
ump
Micro message passing library for threads/tasks communication
-
ach-cell
Atomic Channel
-
csq
A Concurrent Set Queue implemented in Safe Rust
-
simt_cuda_sys
part of simt. cuda driver api bindings
-
snowflake-multi-threaded
The rust-lang implementation of Twitter's id generator algorithm snowflake, it thread safety | Twitter 的id生成器算法snowflake的rust-lang 实现
-
bombs
Efficient single-producer multi-consumer channel types
-
channel_io
Reader implementation on channel of bytes
-
conveyor_belt
Queue and batch processing library
-
ebri
[NOTE: un-tested. use at your own risk.] ebri (ebr-integrated), that is, a
no-std
EBR (Epoch-Based Reclamation) implementation. thanks to the idea fromscc::ebr
. -
object-space
An object store library for highly concurrent program written in Rust
-
slottle
A throttle pool library designed for thread-based concurrency
-
queued_rust
queue type for better privacy managment and data orginization
-
wasm_thread
An std thread replacement for wasm32 target
-
overdose
Fast, Row Oriented, Kotlin, Scala-like dataframe
-
freeswitchrs
Rust bindings for FreeSWITCH
-
rendezvous_swap
Swap data and sync execution between a pair of threads efficiently
-
readlock-tokio
A weird alternative to Arc<RwLock<T>>, using tokio's RwLock
-
one_at_a_time_please
For serialising calls to functions
-
specs-static
extension for Specs that adds custom ids
-
irondash_message_channel
Rust interface to irondash MessageChannel
-
workctl
number of higher-level control mechanisms for concurrent work scheduling, built on standard library concurrency primatives
-
stewart
A minimalist, high-performance, and non-exclusive actor system
-
thread_reviver
A Discord bot to revive any archived threads (to counter Discord's auto-archive function)
-
arrow-rayon
Use parallel iterators for Apache Arrow with rayon
-
tucan
fast, and multithreaded interner with loose type requirement
-
dekker
Dekker's algorithm for mutual exclusion
-
status_executor
Run your work on some context (thread) and get status info back
-
bndpresbufch
Bounds-preserving channel for passing buffers
-
rtfm-core
Core abstractions of the Real Time For the Masses framework
-
atomic-destroy
An value which can be atomically read and destroyed; like an atomic Option
-
arae
Cursed data structures
-
oneshot-broadcast
channel that broadcasts a value once without cloning it
-
ncd
Concurrency library
-
dynamic_ocl
Dynamically-loaded OpenCL bindings
-
bi_channel
Manage bidirectional mpsc channels more conveniently
-
ulock-sys
Rust bindings for Darwin's (e.g. macOS, iOS, ...) not-entirely-public ulock API, which provides futex-like functionality.
-
core_affinity
Manages CPU affinities
-
coarsetime
Time and duration crate optimized for speed
-
concurrent-round-robin
A concurrent wrr implementation for rust
-
voluntary-servitude
Thread-safe appendable list with lock-free iterator
-
amadeus-serde
Harmonious distributed data analysis in Rust
-
wasserglas
A fixed size thread-safe object pool with automatic reattachment
-
global
variables without macros
-
tea-core
Core data structures and traits for tevec
-
is_main_thread
A simply tool to check if current thread is the main one
-
canal
multithreaded concurrency primitives, including queues and channels
-
async_job
async cron job crate for Rust
-
acteur
A safe actor-like framework that just works. Simple, robust, fast, documented.
-
nolock
A collection of Lock-Free Datastructures
-
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.
-
two_way_channel
A two-way communication channel, allowing both clients to send and receive data
-
web_worker
implementing web workers to run rayon-styled concurrent work on wasm
-
update_channel
A channel for single updatable values
-
buf-mutex
Buffered mutexes implementing the reducer parallel-programming pattern
-
crossbeam-skiplist-fd
A long-term maintained forked version of the crossbeam-skiplist for supporting more flexible key comparison customization
-
concurrency_toolkit
Easy switching between std::sync, tokio::sync and loom::sync
-
drop_worker
Tools for worker threads
-
hv-guarded-borrow
Traits and implementations for generic use of "guarded" borrows
-
shmap
A key-value store based on linux shared-memory files (shm) for persisting state across program restarts
-
asparit
Async Parallel Iterators for Rust
-
spliter
way to implement Rayon's ParallelIterator
-
voxel-tiler-core
Convert point clouds to voxel data
-
pulse
async wake signals
-
grandma
A lock-free, eventually consistent, concurrent covertree
-
aligned-task-scheduler
A scheduler that runs tasks at exact minute intervals with an optional offset, ensuring tasks are aligned to precise time boundaries
-
graph_csr
that provides utility functions for manipulating graphs in a CSR format, used as the baseline for constructing powerful graph algorithms
-
jarust
A janus client SDK in Rust
-
hdlibaflexecutor
libafl_cc compiled executor for LKL
-
atomption
AtomicOption implementation with no safety issue
-
kcas
A lock-free, allocation-free multi-word compare-and-swap library
-
inert
lets you use non-Sync values in a Sync way
-
lockfree-ringbuffer
A lock-free ring buffer implementation in Rust
-
ccd
A windows simple, fast chrome_cookie_decryptor
-
captain-workflow-manager
Run and manage jobs that depend on each other on a variety of backends.s
-
pinnable
A Mutex that can be pinned
-
crb-core-web
CRB | Composable Runtime Blocks | WEB
-
htb
Hierarchical token bucket implementation
-
par-array-init
Convenience functions for initializing arrays in parallel
-
emitter_runtime
Runtime support for rs-event-emitter
-
channel-drain
Drain channels with simple syntax
-
command-executor
Command Executor thread pool
-
cargo-steady-state
Code generator for steady_state projects based on a structured dot file
-
parking_lot_mpsc
A port of the Rust std::sync::mpsc module, using the parking_lot concurrency types rather than those in the standard library
-
ocl
OpenCL bindings and interfaces for Rust
-
threadling
Threads as traits
-
atomic_box
A struct which allows multiple threads to safely update and read from a shared non-nullable pointer to heap data
-
comn
my common rust code
-
csplib
CSP for concurrent programming
-
base-threadpool
minimalistic threadpool implementation
-
zestors
A fast and flexible actor-framework for building fault-tolerant Rust applications
-
rusty-variation
deadlock-free session-typed communication
-
uchan
Multi-producer single-consumer channel for message passing
-
disruption_types
Types for communicating with the Discord API and gateway
-
async-events
Waiting for external task completion in asynchronous Rust code
-
no-std-async
Async synchronization primitives for #[no_std] rust
-
iroh-metrics
metrics for iroh
-
crossbeam-epoch
Epoch-based garbage collection
-
bondi
Single producer, multi consumer lock-free ring buffer (experimental)
-
rust-releases-core
Base traits and definitions for rust-releases
-
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. -
stdin_receiver
A structure to help read from stdin in a separate thread, and a method to halt execution
-
asim
Discrete Event Simluation for Async Rust
-
std-mel
Mélodium standard library
-
print_queues
A print queues that can be add from different thread and print on main thread
-
futex
Linux futex-based lock implementations
-
rayon-core
Core APIs for Rayon
-
timely-communication-master
Communication layer for timely dataflow
-
go-spawn
that provides macros to spawn and join threads with minimal boilerplate
-
ligmars
Safe bindings to the LGMP C library
-
cuckoocache
High performance concurrent cache
-
lazy_ref
Implements a non-blocking synchronization primitive for lazy-initialized immutable references
-
quick_cache
Lightweight and high performance concurrent cache
-
fiona
Concurrent runtime written against liburing
-
tyra
Typed Actor System
-
coro
Stackful, first-class asymmetric coroutines
-
throttle
Time-based rate-limit utility
-
concurrent_open_map
A concurrent hashmap implementation in Rust
-
oxidator
A reusable LMAX Disruptor Implementation in Rust
-
microamp-tools
Build a μAMP application
-
jackiechan
Bounded mpsc channel optimized for lazy bulk operations
-
maybe_parallel_iterator
Toggle parallelism with feature flags!
-
threadfin
A thread pool for running multiple tasks on a configurable group of threads
-
tpool
So simple thread pool
-
shipyard
Entity Component System
-
genserver
Elixir inspired async actor library
-
mlt-sys
Bindings for the MLT Multimedia framework
-
async-liveliness-monitor
A Liveliness Monitor for your Asynchronous Runtimes
-
stop-thread
Various ways of stopping threads on various platforms, without requiring the thread to poll
-
atomic-try-update
Primitives that make it easy to implement correct lock-free algorithms
-
lock_order
macro for helping produce a deterministic lock ordering to prevent deadlocks
-
lock_freedom
concurrent data structures and a solution to the ABA problem as an alternative of hazard pointers
-
syncell
Sync alternative to RefCell
-
zkmq
Message Queue, backed by Zookeeper
-
scoped-pool
A flexible thread pool providing scoped threads
-
fused-reader
fused reader type that if writer thread dies while holding armed fuse the reader will get BrokenPipe error
-
ditto
CRDTs for common data structures like maps, sets, vecs, strings, and JSON
-
rayon_iter_concurrent_limit
Limit the concurrency of an individual rayon parallel iterator method with a convenient macro
-
double-checked-cell-async
A thread-safe lazily initialized cell using double-checked locking
-
scherben-map
Concurrent Sharded HashMap for Rust
-
flo_scene_wasm
Supports loading flo_scene subprograms compiled as WASM modules
-
triex
Trivial Executor
-
rayon_croissant
<lqd> bikeshedding the name: something that is mapped folded and collected, a 🥐
-
run-them
A CLI to launch a single command with many workers, serializing the output
-
sched-callback
async callback scheduling
-
waitable
A synchronized (atomic) value container implementing the Mutex+Condvar pattern for efficient blocking waits
-
hyle
Hyle node
-
swimos_byte_channel
SwimOS Byte Channel
-
thread_local_compat
std::thread_local passthrough, designed to be patched on a per-workspace level to provide thread_local on systems without std
-
datacake-crdt
A conflict free replicated datatype based on a hybrid logical clock implementation for building eventually consistent data stores
-
mqb
Lock free in memory message queue broker
-
buffer-redux
Drop-in replacements for buffered I/O in
std::io
with extra features -
locklessness
Composable, lock-free, allocation-light data structures
-
thread-local-object
Per-object thread local storage
-
governor
A rate-limiting implementation in Rust
-
gaffer
Prioritised, parallel job scheduler with concurrent exclusion, job merging, recurring jobs and load limiting for lower priorities
-
orx-concurrent-ordered-bag
An efficient, convenient and lightweight grow-only concurrent data structure allowing high performance and ordered concurrent collection
-
native_db
Drop-in embedded database
-
objectpool
lock-free object pool, support no_std
-
deploy
The
deploy
library to aide writing and debugging of distributed programs, as well as tooling to run them across a cluster -
lock-wrappers
Lock RAII wrappers
-
shared-resource-pool-builder
Create thread pools with a shared resource
-
ferrous_threads
Task runner, thread pools, multi-producer, multi-consumer queues, oh my! This is a crate with helpers for building concurrent software easily and safely
-
archery
Abstract over the atomicity of reference-counting pointers
-
sandbox-ipc
An IPC implementation with an eye toward enabling privilege separation
-
atomiclock_spinlock
spinlock
-
concurrent-biproxy
a proxy that concurrent transfer message from one client to an other client
-
process-events-streaming
Easy to use process with events and data streaming
-
easy-parallel
Run closures in parallel
-
daemonbit-winmutex
Cross-platform daemon lifecycle primitives
-
rcell
A Cell which can hold either an Arc or an Weak smartpointer or be empty
-
colosseum
A variety of arena allocators for Rust, including thread-safe arenas
-
atb
lock-free triple buffer
-
spin_loop
-
moka
A fast and concurrent cache library inspired by Java Caffeine
-
callback_cell
Like an Atomic<Option<Box<FnOnce()>>>
-
rayon_logs
Traces for the rayon work-stealing library
-
rstorage
fast, durable, high concurrent HashMap
-
mutex_logger
logger that usess mutex for thread safty
-
arl
A rate limiter to be used with tokio
-
secc
Implements a Skip-Enabled Concurrent Channel (SECC) for Rust
-
embassy-time
Instant and Duration for embedded no-std systems, with async timer support
-
append-only-vec
Append-only, concurrent vector
-
sea-streamer-file
🌊 SeaStreamer File Backend
-
sentinel-rocket
Sentinel middleware for Rocket
-
acto-rs
Experimental actor library, under development. (renamed from minions_rs).
-
dontshare
Prevent false sharing between data
-
rayon-tlsctx
thread local contexts for rayon loops
-
concurrent-bloom-rs
thread-safe bloom filter
-
thread_binder
Bind rayon pools to limit numa effects
-
pacwrap-core
providing core functionality for pacwrap
-
concache
A fast, concurrent, shared hash map
-
steelmill
A resource manager (dependency injector / factory) designed for distributed systems and simulation testing
-
shared_memory
A user friendly crate that allows you to share memory between processes
-
turbolift
Easy distribution interface 🚡
-
protoflow-crossbeam
Protoflow implements flow-based programming (FBP) for Rust using Protocol Buffers messages
-
paradis-demo
demo functionality for paradis, not intended for use
-
bplustree
Concurrent in-memory B+ Tree featuring optimistic lock coupling
-
hadron-client
The Hadron Rust client library
-
datacake-rpc
A zero-copy, actor-like RPC framework using rkyv
-
atomic-memcpy
Byte-wise atomic memcpy
-
rustc-rayon-core
Core APIs for Rayon - fork for rustc
-
sea-streamer-runtime
🌊 SeaStreamer async runtime abstraction
-
consume
Memory order consume for when it's known that the compiler can't elide the dependency
-
threads_pool
This package provides an easy way to create and manage thread pools, so you don't have to
-
balter-runtime
A load/stress testing framework
-
async-datachannel-wasm
Async Wrapper for WebRTC datachannel in the browser environment
-
tokio-condvar
A Condition Variable for Tokio Applications
-
atom
A safe abstraction around AtomicPtr
-
bastion-executor
Cache affine NUMA-aware executor for Rust
-
mutex-timeouts
let you specify a timeout on a mutex lock
-
talaria
A high performance, cyclic message passing library
-
polyester
Parallel iterator adaptors that accept arbitrary iterators
-
napi_async_local
Extends napi-rs with the ability to run local futures
-
thunk
Primitives for generic lazy evaluation in Rust. This crate requires nightly for
untagged_unions
. -
async-semaphore
An async semaphore
-
eiz
some more code
-
renege
Tracking cache validity using fast concurrent invalidation propogation
-
rdispatcher
Dispatcher for Rust, broadcast and subscribe many to many
-
hurdles
Counter-based thread barrier
-
amfiteatr_classic
some classic game theory problems to research on
-
synevi
A leaderless, consensus library based on Apache Cassandra's Accord algorithm
-
send-cell
Immutable memory region with runtime Send checking
-
thread_lake
A very high level thread pool manager
-
generic_robot_framework
allows you to manage publishers, subscribers and nodes in your Cargo packages. It is made to work with the Generic Robot Framework CLI.
-
caring
Sharing is caring: a safe library for mmap'ing memory in multiple processes
-
amadeus-types
Harmonious distributed data analysis in Rust
-
kik_sync_service
A synchronous threading worker channel for generating the results you want with the data you need
-
sem
IPC semaphore
-
rusty-junctions-macro
Generation and Client Macro API for rusty-junctions
-
rayoff
rayon but it's map-reduce
-
spmc-logger
A single-producer multi-consumer persistent logger
-
mrogalski-looper
Clean abstraction for a single-threaded event loop. Built as a lightweight wrapper around the std::sync::mpsc package.
-
spawns-core
Async runtime agnostic thread context task spawner for Rust
-
skipdb
An embedded, in-memory, zero-copy, atomicity, consistency, MVCC, almost lock-free and serializable snapshot isolation database engine
-
thread-locker
Thread locker library for Rust
-
monotone
counters and queues for coordination in distributed systems
-
rjq
Redis job queue
-
sync_cow
Thread-safe clone-on-write container for fast concurrent writing and reading
-
published_value
Publish a value from one thread to other threads
-
readahead-iterator
Readahead from an iterator on a separate thread, returning items in order and synchronously
-
counter64
64bit increase-only atomic counter for everywhere
-
amadeus-commoncrawl
Harmonious distributed data analysis in Rust
-
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
-
sea-streamer-types
🌊 SeaStreamer Traits & Types
-
mcs
Synchronization primitives based on Mellor-Crummey and Scott’s (MCS) queueing spinlock. This library is usable without
std
. -
fragile
wrapper types for sending non-send values to other threads
-
threadbeam
specialized channel type for beaming data out of a newly spawned thread
-
simple-rc-async
DryadSynth solver for string transformation programs
-
queue-ext
The extended feature of the queue can convert the pop() function of the queue to Stream and the push() function to Sender
-
linux-futex
Futex: A Linux-specific fast user-space locking primitive
-
ump-ng
Micro message passing library for threads/tasks communication
-
storage-map
Concurrent append-only map storage
-
jtp
thread pool, similar to the ThreadPoolExecutor in java
-
quinine
Atomic monotonic containers (Mono{Box,Arc})
-
parking_lot_rt
Parking-lot fork for real-time applications
-
todc-mem
Algorithms for shared-memory distributed systems
-
dynqueue
Dynamically extendable Rayon parallel iterator
-
hv-lease-tracker
no-std compatible tracking of borrow origins, for providing better diagnostics when implementing interior mutability primitives
-
ccl
Fast datastructures for use in highly concurrent systems
-
fenic
test concurrent code
-
cloudi
API
-
linux-rtic
A Real-Time Interrupt-driven Concurrency (RTIC) implementation for Linux
-
scheduler
Binding to set the linux scheduler (priority, policy, affinity, &c.)
-
concurrent-initializer
concurrent initializer to ensure initialization only once per key
-
consumable_vec
generic approach to create a mutual database for multiple producers and consumers
-
poolio
A thread-pool
-
tasic
Tokio, Async_STD, Smol, Interface Crate
-
rustcbuildx
$RUSTC_WRAPPER tool to sandbox cargo builds and execute jobs remotely
-
tokio-bichannel
Bidirectional tokio::sync::mpsc channel
-
cocoro
A more type-safe take on Rust stackless coroutines
-
llq
Wait-free SPSC linked-list queue with individually reusable nodes
-
easy-sqlite
Little sqlite framework
-
dashmap_with_out_t_map_trait
Blazing fast concurrent HashMap for Rust
-
open-coroutine-iouring
The io_uring support for open-coroutine
-
tc-server
TinyChain's cluster server logic, including peer discovery and replication
-
rapidsync
Rapid & threadsafe embedded data stores
-
threadReactive
Synchronous Reactive system
-
open-coroutine-queue
Concurrent work-stealing queue, implemented using st3 and crossbeam-deque
-
multichannel
A mpmc priority multi channel with dynamic channel registration and freezing
-
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.
-
chunker
Minimalistic parallel executor
-
context-coroutine
set of extensions to provide stackful coroutines; it is not officially associated with the context crate
-
blocking_semaphore
performant blocking semaphore
-
malobu
Atomic MPMC Bus
-
futures-rate
easy tools to help Rust applications guide critical resources or code paths from being overwhelmed
-
theatre
A concise async actor model implementation
-
amadeus-aws
Harmonious distributed data analysis in Rust
-
mini-moka
A lighter edition of Moka, a fast and concurrent cache library
-
try-rwlock
Fast non-blocking readers-writer lock
-
key-mutex
Access mutexes by key
-
async-once-watch
Asynchronous and shareable container which value is set once
-
bufchan
buffered MPSC channel
-
paladin-core
distributed algorithm toolkit. Write distributed algorithms without the complexities of distributed systems programming.
-
relay
A lightweight oneshot Future channel
-
sync-cell
A collection of easier to use thread-safe types for the creation of larger thread safe systems
-
ach-linked
Atomic Channel
-
fs-mel
Mélodium core filesystem interaction library
-
raliguard
Lazy rate limit semaphore implementation for your asynchronous code frequency execution
-
os-sync
synchronization primitives based on OS semaphore
-
hv-cell
A no-std port of the
atomic_refcell
crate with additionalArc
-centric functionality -
ach-ring
Atomic Channel
-
mpmc
copy-pasted from old rust stdlib
-
zeet
Work-stealing thread pool built on crossbeam
-
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… -
hv-elastic
Safe and almost-safe abstractions for lengthening lifetimes and
'static
“loaning” of non-'static
types -
hyperbridge
Fast multi-producer multi-consumer channel with async support
-
ga-scheduler
A Genetic Algorithm optimizer designed for scheduling and similar tasks
-
arrows
An actor framework in rust with message durability and ingestion order processing of of messages
-
terminate
abstract logic to terminate threads, coroutines and the like
-
par-map
Parallel map and flat_map
-
tc-fs
TinyChain's transactional filesystem interface layer
-
evelyn
event distribution library
-
rs_taskflow
executing graphs of tasks
-
parsli
Parallel status lines for Rust
-
phoenix-tls
creating always present thread locals
-
async-utils
nothing to see here yet :)
-
faucet
Back-pressured MPMC queue that can be drained after signaling completion
-
tiny-actor
A minimal actor framework for Rust
-
bounded-spsc-queue
A bounded SPSC queue
-
protoflow-flume
Protoflow implements flow-based programming (FBP) for Rust using Protocol Buffers messages
-
mpmcpq
Multi-producer multi-consumer Priority Queue
-
movie
An actor / thread orchestration library / macro / framework
-
crb-parallel
CRB | Composable Runtime Blocks | Parallel
-
stoplight
stoppable tasks/threads
-
once_mut
Safe mutable reference to static variable that can be obtained only once
-
multiqueue
A fast mpmc broadcast queue
-
minicoro-sys
rust binding to minicoro
-
atomic-story
An brief overview of atomics and memory ordering on a multi-threaded context with examples
-
scoped-thread-pool
A flexible thread pool providing scoped threads. Updated fork of https://github.com/reem/rust-scoped-pool
-
ya-ring-buf
Ring Buffer. SPSC channel with direct access for bytes/Copy.
-
slave-pool
thread pool
-
parking_lot_core
An advanced API for creating custom synchronization primitives
-
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
-
daemonbit-rundir
Cross-platform daemon lifecycle primitives
-
concurrent-hashmap
A concurrent hashmap library
-
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
-
brod
A wrapper library providing an API for executing Kafka producers in parallel
-
tractor
Actor system modelled after Pony's actors
-
executor-service
A fast and efficient Thread Pool like Java ExecutorService
-
mpmc-ringbuf
queue
-
async-priority-channel
An async channel where pending messages are delivered in order of priority
-
sentinel-actix
Sentinel middleware for Actix-Web
-
wakerset
no_std, no_alloc storage of Wakers embedded in the Future type
-
arbalest
Like Arc<T> but where weak references don't forbid mutable access
-
busan
An actor implementation for Rust
-
scheduling
job scheduler
-
spsc-bip-buffer
A concurrent, spsc ring-buffer with sized reservations
-
ump-ng-server
Server message dispatch loop for ump-ng
-
request-channel
Async MPSC request-reponse channel
-
async-rwlock
Async reader-writer lock
-
key-rwlock
keyed asynchronous reader-writer locks
-
rpools
A minimalist workerpool for rust
-
mqtt_actor
An mqtt adapters (from port and adapters) to be used with actix actors
-
toktor
A small tokio-based Actor framework
-
npnc
Lock-free queues
-
blasoxide-mt
multithreading for blasoxide
-
spinning
Mutexes and SIX locks implemented by spinning
-
statman
Stat Manager
-
gemino
A multi producer multi consumer (MPMC) broadcasting channel
-
momen
low overhead thread pool
-
rustix-futex-sync
Linux futex-based synchronization
-
read-write-api
interface to unify single-threaded code and RwLocks-based code
-
libmcs
A MCS Lock Library
-
atomic_immut
Atomic immutable value
-
kai-cli
Kai - todo.txt task scheduler
-
amfiteatr_proc_macro
Procedural macro crate for amfiteatr_* crates
-
system-graph
experimental alternative for shred's Dispatcher
-
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
-
shrink_pool
A thread pool which agressively terminates its threads as soon as they are idle
-
scheduled-executor
Single and multi-threaded task scheduler
-
open-coroutine-hooks
The syscall hook for open-coroutine
-
horde
threads
-
fibril
implementing distributed systems with commmunicating fibers
-
spin-seq
Fork of the
seqlock
crate that can be used on bare metal -
fuze
A mechanism to wait for a single signal which can be checked at any time
-
wasefire-sync
Portable non-blocking mutex
-
ping-pong-cell
An atomic cell for up to two threads
-
lock_cell
A custom locking cell type written in Rust
-
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.
-
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
-
agner-actors
An actor toolkit inspired by Erlang/OTP (actors)
-
padlock
Safely acquire RwLock/Mutex locks
-
mula
Share expensive computation with various requesters
-
paradis-core
core functionality for paradis
-
stretto
high performance thread-safe memory-bound Rust cache
-
simple_event_map
event map based on channels, provides a receiver that is either blocking or async
-
macgyver-lock
Memcache backed lock implementation
-
protoflow-blocks
Protoflow implements flow-based programming (FBP) for Rust using Protocol Buffers messages
-
refptr
Inherently reference counted structs
-
melodium-engine
Mélodium core engine and executor implementation
-
pairlock
A reader-writer lock with wait-free reads
-
pour
Optionally consed radix tries for fast set operations
-
ringtail
Efficient ring buffer for byte buffers, FIFO queues, and SPSC channels
-
rw_lease
Fast Reader-Writer lock with reader draining support. Based on a single (parameterisable) atomic usize.
-
son_of_grid_engine
Interface with son of grid engine (formerly sun grid engine) to run rust programs on clusters
-
datacake-node
The core cluster membership system built ontop of Quickwit's chitchat
-
mtlog
Multi-threaded logger with support for log files
-
ach
Atomic Channel
-
access-queue
limit the number of simultaneous accesses to a value
-
read-cell
Read-only Cell counterpart
-
balter-core
A load/stress testing framework
-
gothack-future-parking_lot
An "as simple as possible" Future implementation for parking_lot
-
sorted-channel
sorted message-based communication channel
-
thread-safe
Container that allows thread safety for thread-unsafe objects
-
navvy
MPSC Channel broker allowing channels of different types to be stored in a single data structure
-
thread-broadcaster
A SPMC (Single producer multi consumer) broadcasting channel to broadcast notifications between threads
-
hybrid-lock
A hybrid lock with optimistic locking
-
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
-
indexed-ring-buffer
An indexed multiple readable spsc ring buffer
-
tpx
Task scheduler
-
open-coroutine-core
The open-coroutine is a simple, efficient and generic coroutine library
-
threatpool
thread pool
-
testtools
Helpers for eliminating boilerplate code in tests
-
simple-mutex
A mutex more efficient than std and simpler than parking_lot
-
tasque
thread pool library
-
yastl
scoped threadpool library
-
smol-axum
Integrations between
smol
andaxum
-
atomic-bus
Atomic MPMC Bus
-
rtic-monotonics
that provides implementations of the Monotonic trait from rtic-time
-
tinypool
thread pool implementation in Rust
-
delay-queue
A concurrent unbounded blocking queue where each element can only be removed when its delay expires
-
deploy-common
Common components for the
deploy
andfabric
crates -
blinkcast
Fast, bounded, multiple-producer, multiple-consumer, lossy, broadcast channel
-
RobotS
Actor framework
-
unknownrori-simple-thread-pool
A lighweight thread pool for networking and other stuff
-
async-handle
A reference-counted async RwLock
-
synctree
Thread-safe tree data structure
-
daemonbit-lockfile
Cross-platform daemon lifecycle primitives
-
hv-atom
Convenient abstractions for atomic operations on smart pointer/reference types, based on the
atom
crate -
television-channels
The revolution will be televised
-
qadapt-spin
Synchronization primitives based on spinning. They may contain data, are usable without
std
, and static initializers are available -
jobsteal
A work-stealing fork-join threadpool written in Rust
-
actress
actor library for Rust
-
deterministic
building blocks for testable systems
-
lightproc
Lightweight process abstraction for Rust
-
rayon-macro
Macros enabling parallelism using the rayon crate
-
rayon-core-wasm
Core APIs for Rayon
-
jxl-threadpool
Internal crate of jxl-oxide to abstract over thread pool implementation
-
adirector
asynchronous tokio task spawner with a limited size
-
futex-queue
An efficient MPSC queue with timer capability based on Linux futex. Suitable for real-time applications.
-
cpq
A Concurrent Priority Queue implemented in Safe Rust
-
smart-threadpool
A smart thread pool implementation in Rust
-
rtic-core
Core abstractions of the Real-Time Interrupt-driven Concurrency framework
-
optimistic-cell
lock-like structure for low-overhead optimistic concurrency
-
double-checked-cell
A thread-safe lazily initialized cell using double-checked locking