-
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
-
flume
A blazingly fast multi-producer channel
-
async-lock
Async synchronization primitives
-
ctrlc
Easy Ctrl-C handler for Rust projects
-
signal-hook
Unix signal handling
-
async-channel
Async multi-producer multi-consumer channel
-
crossbeam
Tools for concurrent programming
-
ringbuf
Lock-free SPSC FIFO ring buffer with direct access to inner data
-
threadpool
A thread pool for running a number of jobs on a fixed set of worker threads
-
jobserver
GNU Make jobserver for Rust
-
triomphe
A fork of std::sync::Arc with some extra functionality and without weak references (originally servo_arc)
-
loom
Permutation testing for concurrent code
-
blake2s_simd
a pure Rust BLAKE2s implementation with dynamic SIMD
-
thread-priority
managing threads priority and schedule policies
-
serenity
Discord API
-
kanal
The fast sync and async channel that Rust deserves
-
sled
Lightweight high-performance pure-rust transactional embedded database
-
mpi
Message Passing Interface bindings for Rust
-
sync_wrapper
enlisting the compiler's help in proving the absence of concurrency
-
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
-
rtrb
A realtime-safe single-producer single-consumer ring buffer
-
thingbuf
I'm at the buffer pool. I'm at the MPSC channel. I'm at the combination MPSC channel and buffer pool.
-
archery
Abstract over the atomicity of reference-counting pointers
-
waker-fn
Convert closures into wakers
-
shared_child
using child processes from multiple threads
-
concread
Concurrently Readable Data-Structures for Rust
-
stateright
A model checker for implementing distributed systems
-
atomic_float
Floating point types which can be safely shared between threads
-
corosensei
A fast and safe implementation of stackful coroutines
-
may
Rust Stackful Coroutine Library
-
rayon-cond
Experimental iterator wrapper that is conditionally parallel or serial
-
local-channel
A non-threadsafe multi-producer, single-consumer, futures-aware, FIFO queue
-
bus
A lock-free, bounded, single-producer, multi-consumer, broadcast channel
-
flurry
Rust port of Java's ConcurrentHashMap
-
try-lock
A lightweight atomic lock
-
radium
Portable interfaces for maybe-atomic types
-
shuttle
testing concurrent Rust code
-
fragile
wrapper types for sending non-send values to other threads
-
diatomic-waker
An async, lock-free synchronization primitive for task wakeup
-
ratelimit
ratelimiter that can be shared between threads
-
concurrent-queue
Concurrent multi-producer multi-consumer queue
-
leaky-bucket
A token-based rate limiter based on the leaky bucket algorithm
-
sdd
Scalable lock-free delayed memory reclaimer
-
scheduled-thread-pool
A scheduled thread pool
-
jobslot
GNU make jobserver for Rust
-
triple_buffer
triple buffering, useful for sharing frequently updated data between threads
-
futures-intrusive
Futures based on intrusive data structures - for std and no-std environments
-
seize
Fast, efficient, and predictable memory reclamation for concurrent data structures
-
rustc-rayon
work-stealing parallelism for Rust - fork for rustc
-
tachyonix
A very fast asynchronous, multi-producer, single-consumer bounded channel
-
wasm_thread
An std thread replacement for wasm32 target
-
mmap-sync
package allowing sharing of data between processes in a wait-free and zero-copy fashion from mapped memory
-
atomic_refcell
Threadsafe RefCell
-
concurrent-map
a lock-free linearizable B+ tree
-
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
-
maitake-sync
No-std async synchronization primitives from Maitake
-
surrealkv
A low-level, versioned, embedded, ACID-compliant, key-value database for Rust
-
async-condvar-fair
Condition variables for async Rust
-
gix-worktree
gitoxide project for shared worktree related types and utilities
-
parking
Thread parking and unparking
-
throttle-server
Provide semaphores for distributed systems via an http interface
-
mpstthree
implementing Multiparty Session Types for 2 or more participants
-
resman
Runtime managed resource borrowing
-
gst-plugin-threadshare
GStreamer Threadshare Plugin
-
process_control
Ergonomically run processes with limits
-
guardian
owned mutex guards for refcounted mutexes
-
automerge
A JSON-like data structure (a CRDT) that can be modified concurrently by different users, and merged again automatically
-
hydra
A framework for writing fault tolerant, highly scalable applications with the Rust programming language
-
atomig
Generic, convenient and lock-free
std
atomics viaAtomic<T>
. Can be used with many primitive types (including floats) and with custom types. -
crossbeam-channel
Multi-producer multi-consumer channels for message passing
-
twincatads-rs
Rust wrapper for TwinCAT ADS library provided with Beckhoff TwinCAT
-
disruptor
Low latency inter-thread communication via a ringbuffer (inspired by the LMAX Disruptor)
-
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 -
paralight
A lightweight parallelism library for indexed structures
-
executors
A collection of high-performance task executors
-
fdup
find duplicate files recursively and in parallel
-
sea-streamer
🌊 The stream processing toolkit for Rust
-
inline-array
efficient immutable inlinable byte array
-
chili
low-overhead parallelization library
-
ppl
A structured parallel programming library for Rust
-
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
-
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
-
indicatif-log-bridge
Bridge the log crate and indicatif to stop log lines from mixing up with progress bars
-
fault-injection
fault injection, concurrency delay injection, and error source annotation
-
atomic-time
AtomicDuration
,AtomicOptionDuration
,AtomicSystemTime
,AtomicOptionSystemTime
,AtomicInstant
andAtomicOptionInstant
for Rust -
shred
Dispatches systems in parallel which need read access to some resources, and write access to others
-
crossbeam-utils
concurrent programming
-
open-coroutine
efficient and generic stackfull-coroutine library
-
safe-lock
A lock struct with a
const fn
constructor and nounsafe
- ARCHIVED -
aws-sdk-s3-transfer-manager
A high performance Amazon S3 transfer manager for Rust
-
messaging_thread_pool
aiding the creation of typed thread pool of objects that is communicated with via channels
-
parallel-sh
Execute commands in parallel
-
uid
creation of unique IDs
-
readlock
A weird alternative to Arc<RwLock<T>>
-
runnel
the pluggable io stream. now support: stdio, string io, in memory pipe
-
happylock
Free deadlock prevention
-
samsa
Rust-native Kafka/Redpanda protocol and client implementation
-
append-only-vec
Append-only, concurrent vector
-
mcslock
Mellor-Crummey and Scott contention-free lock for mutual exclusion, referred to as MCS lock
-
pausable_clock
A source of time information that can be paused and resumed
-
deadqueue
Dead simple async queue
-
fmutex
Cross-platform mutual exclusion across processes on a file or path
-
infinitree
Embedded, encrypted database with tiered cache
-
rs-store
Redux Store for Rust
-
memo-map
implementing a synchronized map for memoization
-
oqueue
Non-interleaving multithreaded output queue
-
pueue
A cli tool for managing long running shell commands
-
rclite
small, fast, and memory-friendly reference counting compatible with Arc and Rc APIs
-
rtsc
Real-time Synchronization Components
-
async_nursery
Primitive for structured concurrency
-
recloser
A concurrent circuit breaker implemented with ring buffers
-
rearch
Re-imagined approach to application design and architecture
-
sync_file
Files that can be read concurrently
-
gcra
A basic implementation of GCRA algorithm for rate limiting
-
gabriel2
Indeed, an actor library based on Tokio, written in Rust
-
oxidd-manager-index
Index-based manager implementation for OxiDD
-
ordered-channel
A channel that always receives messages in the correct order, even if they were sent out of order
-
hexchat-unsafe-plugin
Lets you write native HexChat plugins in mostly-safe Rust
-
p3-maybe-rayon
Feature-gated wrapper around rayon
-
io-reactor
Concurrent I/O resource management using reactor pattern
-
atomic-maybe-uninit
Atomic operations on potentially uninitialized integers
-
threadbound
Make any value Sync but only available on its original thread
-
loole
A safe async/sync multi-producer, multi-consumer channel
-
pi_share
rc, arc, lock, atomic
-
congee
ART-OLC concurrent adaptive radix tree
-
ringbuffer-spsc
A fast thread-safe single producer-single consumer ring buffer
-
rcu_cell
a lockless rcu cell implementation
-
botcore
Production-grade asynchronous bot engine with enterprise observability features
-
mco
Rust Coroutine Library like go
-
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…
-
resilient-rs
fault tolerance, including retry strategies, backoff mechanisms, and failure handling
-
st3
A very fast lock-free, bounded, work-stealing LIFO queue
-
beekeeper
A full-featured worker pool library for parallelizing tasks
-
trauma
Simplify and prettify HTTP downloads
-
minstant
A drop-in replacement for
std::time::Instant
that measures time with high performance and high accuracy powered by TSC -
mutex
An abstraction over closure-based mutexes
-
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
-
rc_event_queue
VecDeque-like fast, unbounded, FIFO, concurent read-lock-free message queue
-
clashmap
Sharded hashmap suitable for fast concurrent access
-
pumps
Eager streams for Rust
-
batch-aint-one
I got 99 problems, but a batch ain't one
-
renege
Tracking cache validity using fast concurrent invalidation propogation
-
nbio
Non-Blocking I/O
-
orx-concurrent-iter
A thread-safe and ergonomic concurrent iterator trait and efficient lock-free implementations
-
leapfrog
A fast, lock-free concurrent hash map
-
signals_receipts
exfiltration of the receipt of POSIX signals
-
session_log
session log library for Rust
-
thingvellir
a concurrent, shared-nothing abstraction that manages an assembly of things
-
boxcar
A concurrent, append-only vector
-
atomic_once_cell
Thread-safe and lock-free OnceCell and Lazy
-
steady_state
Framework for building long running low latency actor based services on Linux. Provides visual telemetry to watch data flows between actors. Uses Erlang style supervisors to defend…
-
bend-lang
A high-level, massively parallel programming language
-
concurrent_arena
u32 concurrent insertion/removal arena that returns ArenaArc
-
pbrt-r3
pbrt-v3
-
arccstr
Thread-safe, reference-counted null-terminated immutable strings
-
std-ext
Extend the standard library functionality
-
picokafka
Kafka library for tarantool-module based on librdkafka
-
napi-calm-down
N-API bindings
-
orx-parallel
A performant and configurable parallel computing library for computations defined as compositions of iterator methods
-
rtic-monotonics
that provides implementations of the Monotonic trait from rtic-time
-
elysees
A fork of triomphe, now with more pointer trickery
-
schedules
A lightweight Rust library for managing operations across multiple time scales
-
atomic-arena
Generational arena that allows reserving keys from other threads
-
async-event
An efficient async condition variable for lock-free algorithms
-
throttle-client
Client for Throttle. Throttle is an http semaphore service, providing semaphores for distributed systems.
-
paradis
Parallel processing with disjoint indices
-
onering
High throughput synchronous queue
-
rs-event-emitter
simulate promise implementation for rust
-
actify
An intutive actor model with minimal boilerplate
-
no_deadlocks
A Runtime Deadlock Debugger
-
sharded_mutex
No per-object memory overhead locks. Pseudo atomic ops for Copy/PartialEq types.
-
sovran-arc
Memory management swift-isms brought to Rust
-
atom_box
A safe idiomatic Rust implementation of Atomic Box using hazard pointers
-
tonari-actor
A minimalist actor framework aiming for high performance and simplicity
-
spinning_top
spinlock crate based on the abstractions provided by
lock_api
-
nexus-actor-utils-rs
Nexus Actor
-
sanitizers
Interfaces and FFI bindings for the sanitizers interfaces
-
gettid
Helper to get an integer ID for the current thread
-
atomic-take
Atomically take a value out of a container once
-
choir
Task Orchestration Framework
-
jod-thread
std::thread which joins on drop by default
-
desync
A hassle-free data type for asynchronous programming
-
que
A high performance channel with optional backpressure, interprocess capability, and a multiconsumer mode
-
shmap
A key-value store based on linux shared-memory files (shm) for persisting state across program restarts
-
cargo-steady-state
Code generator for steady_state projects based on a structured dot file
-
async-local
For using thread locals within an async context across await points
-
pagetable
Wait-free 4-level 64-bit pagetable for roughly-contiguous keys
-
simple_coro
(ab)using async/await to write simple state-machine based coroutines
-
potential
PubSub lib with sync and async API
-
atomptr
A safe copy-on-write wrapper around
AtomicPtr
with some extra tricks -
pi_arr
lock-free & auto-expansion array
-
dispatch
Rust wrapper for Apple's Grand Central Dispatch
-
nebkor-maelstrom
synchronous client for creating Maelstrom distributed clients
-
rw-cell
Write data to cell from anything place your application without copy, lock and reading in one place
-
rsvow
A Rust-like implementation of JavaScript's Promise mechanism
-
mintex
minimal mutex
-
stdin-nonblocking
Dependency-less non-blocking stdin reader using background threads. Supports streaming and immediate fallback defaults.
-
may_actor
Actor library based on MAY
-
liner_broker
Redis based message serverless broker
-
atomic-wait
Cross-platform atomic wait and wake (aka futex) functionality
-
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
-
magnetic
Low-latency lock-free queues
-
simd-itertools
SIMD-accelerated alternatives for common operations like contains, max, find etc
-
sharded-offset-map
A map from u64 to T that can be written from multiple threads
-
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).
-
thepipelinetool
readers used for thepipelinetool
-
balter
A load/stress testing framework
-
file-per-thread-logger
A logging implementation that writes logs in one file per thread
-
pi_async_transaction
Asynchronous abstraction for transactions
-
codas-flow
Low-latency, high-throughput bounded queues ("data flows") for (a)synchronous and event-driven systems
-
skipdb
An embedded, in-memory, zero-copy, atomicity, consistency, MVCC, almost lock-free and serializable snapshot isolation database engine
-
virtual-buffer
A cross-platform library for dealing with buffers backed by raw virtual memory
-
crossbeam-queue
Concurrent queues
-
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.
-
aarc
Atomically updatable variants of Arc and Weak for lock-free concurrency
-
mea
A runtime-agnostic library providing essential synchronization primitives for asynchronous Rust programming
-
wdk-mutex
An idiomatic Rust mutex type for Windows kernel driver development
-
api-rate-limiter
rate limiter for Rust APIs
-
cfavml
CF's Accelerated Vector Math Library providing SIMD optimzied routines for vector operations
-
haphazard
Dynamic memory management for lock-free data structures using hazard pointers
-
tatl
in-process alerting
-
commonware-runtime
Execute asynchronous tasks with a configurable scheduler
-
rearch-tokio
Re-imagined approach to application design and architecture
-
portable_atomic_enum
An attribute to create an portable atomic wrapper around a C-style enum
-
retry-if
A tokio-compatible attribute-macro for decorating methods and functions with an exponential backoff
-
spawns
Async runtime agnostic thread context task spawner for Rust
-
utils-atomics
Various atomic utils
-
paraseq
A minimal-copy parser for FASTA and FASTQ files built for paired parallel processing
-
semka
Semaphore implementation
-
lock-free-static
Lock-free static variables
-
linked
Create families of linked objects that can collaborate across threads while being internally single-threaded
-
forte
A low-overhead thread-pool with support for non-static async closures
-
gix-lock
A git-style lock-file implementation
-
mpsc
mpsc channel
-
channel
Rust advanced queue library
-
pi_key_alloter
lock free Key(idx:u32, version:u32) alloter
-
melodium
Dataflow-oriented language & tool, focusing on treatments applied on data, allowing high scalability and massive parallelization safely
-
torq_lang
A programming language for concurrent dataflow
-
timeslice
periodic time slice scheduler
-
sharded-vec-writer
Write parts of a Vec from different threads
-
par_slice
Slices that may be accessed from multiple threads with different levels of safety
-
flag-bearer
Generic async semaphores
-
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
-
async_once
async once tool for lazy_static
-
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
-
lock-hierarchy
Prevent dead locks by enforcing lock hierarchies
-
spools
Content scraping library for Instagram's Threads
-
async-atomic
Atomics which can be subscribed to and asynchronously notify when updated
-
watchable
RwLock-like type that is compatible with both multi-threaded and async code
-
myriam
Actor model implementation for local and remote actors
-
amfiteatr_classic
some classic game theory problems to research on
-
rust_supervisor
An Erlang-inspired process supervision library for Rust
-
rush_expr_engine
The rules engine is based on the rete algorithm
-
limnus-default-schedulers
default schedulers for limnus. Main, Fixed and Render
-
orx-concurrent-bag
An efficient, convenient and lightweight grow-only concurrent data structure allowing high performance concurrent collection
-
whisk
fast lockless async channels
-
svix-ksuid
A pure Rust and fully tested KSUID implementation
-
amadeus
Harmonious distributed data processing & analysis in Rust. parquet postgres aws s3 cloudfront elb json csv logs hadoop hdfs arrow common crawl
-
rayon-progress-bar
work-stealing parallelism for Rust
-
rucron
Job Scheduling Crate
-
hecs-schedule
shedulable systems and parallel execution for hecs
-
rust_observer
Express telemetry rust SDK
-
multipool
A configurable thread pool with optional work-stealing support and task priority scheduling
-
stele
An atomic Vec-like structure with no copying on allocation
-
crossfire
channels for async and threads
-
drain
that supports graceful shutdown
-
bcast
Low latency broadcast (SPMC) buffer designed to work with shared memory
-
notmuch
Rust interface and bindings for notmuch
-
orchestrator_lock
A Mutex whose access order is managed by a separate thread
-
sigq
Queue that signals waiting consumers about node availability
-
sovran-state
state management for Rust
-
rusturnate
A sync or async mutex, with or without timeouts
-
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…
-
easy-threadpool
A relatively simple thread pool which you can send jobs to
-
maybe-rayon
Either acts as rayon or creates a single-threaded facade
-
iterator_ilp
Iterator extensions for instruction-parallel reductions
-
slog-atomic
Atomic run-time controllable drain for slog-rs
-
crawly
A lightweight async Web crawler in Rust, optimized for concurrent scraping while respecting
robots.txt
rules -
xstm
A Rust-implemented Software Transactional Memory (STM) library using TL2 (Transactional Locking II) algorithm
-
pariter
Parallel iterator processing
-
tetanus
A custom utils library for some common unsafe operations
-
concurrent-slotmap
A lock-free concurrent slotmap
-
evtcall
Rust Event Driven Framework
-
affinitypool
running blocking jobs on a dedicated thread pool with CPU core affinity
-
thread-manager
A streamlined Rust library for efficient thread pooling and parallel job execution, designed for simplicity, flexibility, and performance
-
lever
Pillars for Transactional Systems and Data Grids
-
txn_lock
support transactional versioning
-
miyabi_scheduler
Thread pool scheduler with extra specific abilities
-
amity
Concurrency algorithms
-
init-once
Concurrent, non-blocking lazy initialization of values
-
rtic-sync
Synchronization primitives for asynchronous contexts
-
mpvipc
A small library which provides bindings to control existing mpv instances through sockets
-
voxel-tiler-core
Convert point clouds to voxel data
-
rocketapi
Unofficial RocketAPI Rust SDK for Instagram & Threads Private API 2024
-
synchronoise
Synchronization primitives that build upon the standard library
-
msgpass
Thin wrapper to a Message Passing Interface (MPI)
-
parel
run linux commands in parallel
-
pacwrap-agent
Executable agent for conducting containerized transactions
-
atomic_enum
An attribute to create an atomic wrapper around a C-style enum
-
perthread
ThreadMap structure for accessing PerThread thread local variables form a static context
-
split_channel
stream-of-messages abstraction with split send/recv channels
-
blocking-threadpool
A thread pool for running a number of jobs on a fixed set of worker threads
-
patrolilo
Job scheduler with integrated NTFY notifications
-
ltpp-output
An atomic output library based on Rust that supports output functionalities through functions, builders, and other methods. It allows customization of text and background colors.
-
rust-box
odd set of tools for Rust programming
-
mu_uefi_tpl_mutex
Task Priority Level (TPL) mutual exclusion support
-
spmc
channel
-
nexus-actor-remote-rs
Remote library for Nexus Actor
-
dir-lock
file-system-based mutex
-
locktick
Automated lock accounting & profiling
-
td_rthreadpool
thread wrapper for Rust
-
ballista-scheduler
Ballista Distributed Compute - Scheduler
-
pochta
Addressable channel registry
-
descord
A minimal discord api wrapper
-
parallel-stream
Data parallelism library for async-std
-
rt_map
Runtime managed mutable borrowing from a map
-
mpmc-async
A multi-producer, multi-consumer async channel with reservations
-
shipyard_scenegraph
Scenegraph for Entity Component System
-
cocmd
cmdops tool for dev teams
-
benjamin_batchly
Low latency batching tool. Bundle lots of single concurrent operations into sequential batches of work.
-
protoflow-zeromq
Protoflow implements flow-based programming (FBP) for Rust using Protocol Buffers messages
-
circuit_breaker
Circuit Breaker pattern for building resilient and fault-tolerant systems
-
async-stm
Asynchronous Software Transactional Memory
-
omango
Concurrency collections
-
thread_local_collect
Supports the collection and aggregation of thread-local data across threads
-
parallel-processor
Framework to manage asynchronous execution of multiple compute units communicating using messages
-
sync42
synchronization tools
-
armc
that facilitates Mutex access to variables
-
icicle-core
GPU ZK acceleration by Ingonyama
-
atomicell
Multi-threaded RefCell on atomics
-
fluxion
actor framework written in rust and designed for distributed systems
-
fast-stm
Performance-focused implementation of software transactional memory. Allows composable atomic operations
-
swap-buffer-queue
A buffering MPSC queue
-
thread_io
performing I/O in background thread
-
sea-streamer-fuse
Stream processing toolbox
-
cyclic_pipe
providing fixed-size, buffer pre-allocated cyclic pipe which support multi-producer and multi-consumer concurrent access
-
async-fifo
MPMC & oneshot channels with (a)sync API
-
rust_kits
kits
-
smolscale2
hitdns fork of original smolscale
-
circ
Efficient referenced counted pointers for non-blocking concurrency
-
sharded-thread
Expirement for now
-
arcslab
Slab, but with reference counted items
-
crossbeam-skiplist-mvcc
Support MVCC (Multiple Version Concurrent Control) for
crossbeam-skiplist
-
clhlock
Craig and, indenpendently, Magnussen, Landin, and Hagersten queue lock for mutual exclusion, referred to as CLH lock
-
send_cells
Safe and unsafe cells implementing Send/Sync
-
restd
A re-implementation of various std features
-
atom
A safe abstraction around AtomicPtr
-
kind2
A pure functional functional language that uses the HVM
-
java-threadpool
这是一个跟java ThreadPoolExecutor线程池 使用方式基本相同的线程池
-
tensr
A high-performance, cross-platform, multi-backend tensor/array library for Rust
-
win-kernel
windows-kernel
-
scope-lock
Safely extend lifetimes
-
lock_api
Wrappers to create fully-featured Mutex and RwLock types. Compatible with no_std.
-
mailboxxy
micro actor library for rust
-
hydra-dashmap
A fork of dashmap for the hydra framework
-
topograph
A miniscule thread pool and toposort scheduler
-
operational-transform
Operational Transformation
-
critical-once-cell
Thread-safe OnceCell and Lazy backed by critical section
-
sprinter
Run parallel queued tasks
-
orama-js-pool
Create a pool of JavaScript engines to invoke JavaScript code concurrently
-
atomic_pincell
Threadsafe pinnable RefCell
-
tlrepo
Thread-local git2::Repository, shareable across threads
-
disruptor-rs
A high-performance ring buffer implementation of the LMAX Disruptor pattern
-
with_daemon
An async client-daemon abstraction framework
-
resilience-rs
Resilience patterns in Rust
-
ruget
Alternative to wget written in Rust
-
kueue
A robust, user-level, work-stealing, distributed task scheduler
-
sqrtx
Square root calculation
-
parallel_operations
perform binary operations in parallel using threads
-
may_queue
May's internal queue library
-
cachemap2
A concurrent insert-only hashmap for caching values
-
seqlock
A reader-writer lock that provides extremely fast read access without starving writers
-
sids
sample actor-model scheme providing abstraction over actor types and messages that can be sent across threads
-
pollex
Arm instruction manipulator
-
freezebox
deref'able lazy-initialized container
-
synapps
event dispatcher for Rust applications. It allows senders to send messages to topics. Subscribers will then receive the message based on their subscription policy.
-
mpsc_requests
mpsc channels but with a response
-
moro-local
Experimental structured concurrency support for async Rust (similar to trio's nurseries). Works with non-Send futures on stable Rust.
-
ebr
epoch-based reclamation with low cacheline ping-pong
-
trc
A faster Arc
-
permit
A struct for cancelling operations
-
sync-cell-slice
Cells and slices that are accessible from multiple threads
-
flashmap
A lock-free eventually consistent concurrent hash map
-
listfree
lockfree prepend-only list
-
xarray
version of the XArray with copy-on-write capabilities
-
torn-key-pool
A generalised API key pool for torn-api
-
onceinit
仅可设置一次数据的类型。
-
rose_bloom
A concurrent growing element size linked list with stable pointers
-
aranya-afc-util
using Aranya Fast Channels
-
papaya
A fast and ergonomic concurrent hash-table for read-heavy workloads
-
command-executor
Command Executor thread pool
-
ccutils
Collection of utils from the CylonCore project
-
notmad
life-cycle manager for long running rust operations
-
ohos-sys
Bindings to the native API of OpenHarmony OS
-
snowdon
A lightweight thread-safe snowflake ID implementation for Rust
-
bastion
Fault-tolerant Runtime for Rust applications
-
par-iter-sync
Parallel Iterator With Sequential Output
-
kontroli
Type checking for the lambda-Pi calculus modulo rewriting
-
bound
Wrap lock guards and other structs along with the locks or other data they are derived by shared reference from, in a struct you can pass around and store anywhere
-
concurrent_tor
A comprehensive scraping runtime
-
twice-cell
Like
once-cell
, except you set the value twice -
neon-runtime
Bindings to the Node.js native addon API, used by the Neon implementation
-
synchronized
Convenient and simple macro for code synchronization in multithreading
-
granite_reckoner
aggregator enabling basic statistical operations on Vec<T> in the specified number of threads. Works for all Rust's built-in numeric types.
-
anylock
Polymorphic Locks
-
node-replication
An operation-log based approach that transform single-threaded data structures into concurrent, replicated structures
-
rsevents
Manual and auto reset events for signaling threads and writing new synchronization primitives like semaphores
-
nblock
Non-Blocking Runtime
-
env-lock
Set and lock environment variables for tests
-
uringy
single-threaded concurrency runtime for Rust based on io_uring
-
par
Session types, as an implementation of linear logic with MIX
-
buf-mutex
Buffered mutexes
-
lock_ext
Extensions to std::sync::Mutex
-
cuneiform-fields
Field level [no_std] cache optimizations for Rust
-
tari_shutdown
A convenient shutdown signal
-
up-transport-zenoh
Zenoh Rust Transport library implementation of the Eclipse uProtocol
-
television-utils
The revolution will be televised
-
spinwait
C#'s SpinWait type for lightweight spinning
-
open-coroutine-hook
The syscall hook for open-coroutine
-
direct_ring_buffer
A high-performance, lock-free ring buffer for single-producer, single-consumer scenarios
-
wasm-futures-executor
Executor for asynchronous task based on wasm web workers
-
ctxs
显式的代码上下文管理设施
-
evolution-converter
Converter implementations for evolution
-
readlock-tokio
A weird alternative to Arc<RwLock<T>>, using tokio's RwLock
-
tpool
So simple thread pool
-
pinned-mutex
Mutex wrappers with structural pinning
-
print_queues
A print queues that can be add from different thread and print on main thread
-
congestion-limiter
Dynamic congestion-based concurrency limits for controlling backpressure
-
simple-semaphore
🔐 A lightweight implementation of a Semaphore in Rust
-
logical-expressions
working with logical expressions
-
progpool
Job pool with terminal progress bar
-
boomerang
Deterministic Middleware for Robotics
-
miracle
Generic pub/sub resource server for Project Lighthouse models
-
cas-lib
Core lib for CAS
-
cheap-clone
A trait which indicates that such type can be cloned cheaply
-
gfwx
Good, Fast Wavelet Codec (Rust)
-
log-mdc
A mapped diagnostic context (MDC) for use with the
log
crate -
eventbus-tiny
A small, dependency-free crate that provides a multi-producer broadcast-consumer event bus
-
mt-debug-counters
support high performance debug counters for heavy multithreaded applications
-
async_logger
Asyncronous logger allows writing arbitrary slices to a memory buffer, which then processed by a writer in it's own thread
-
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
-
r3bl_core
Helper crate for r3bl_tui and r3bl_tuify crates. Used by workspace in https://github.com/r3bl-org/r3bl-open-core
-
putex
process mutex
-
sentry_arroyo
working with streaming data
-
cortex-m-rtic
Real-Time Interrupt-driven Concurrency (RTIC): a concurrency framework for building real-time systems
-
turbo-metrics
Toolkit to compute quality metrics fast using a GPU
-
piscina
generic pool that supports both sync and async
-
smart_channel
channel subscription system
-
snowflake-rs-impl
Twitter's Snowflake ID generation algorithm
-
lockmap
A high-performance, thread-safe HashMap implementation for Rust that provides fine-grained locking at the key level
-
thread-monitor
Thread monitor
-
mutex_trait2
Generic mutex trait
-
redlock
distributed locking mechanism built on top of Redis
-
sync-unsafe-cell
A backport of the SyncUnsafeCell standard library type for use in older Rust versions
-
latches
A downward counter (CountDownLatch) which can be used to synchronize threads or coordinate tasks
-
bevy_gpu_compute
Empowering anyone to leverage GPU-acceleration with as little barrier-to-entry as possible
-
net_link
NetLink is a decentralized networking tool built on the 'rustp2p' library
-
folklore
A lock-free concurrent hash map
-
sem_safe
Safe usage of POSIX Semaphores (
sem_post
,sem_wait
, etc) -
adaptive-barrier
Barrier with adaptable number of thread subsciptions
-
batch-processing
A batch library for processing a list of items in parallel
-
uactor
The fastest and most modular actor system that doesn't force you to pay for what you don't need
-
pi_store
File storage
-
interaction-calculus
A parallel model of computation
-
simple_mdns_client
mdns client
-
hipthread
no-std thread library based on pthread
-
atomic-destructor
Atomic destructor for multi-threaded env
-
bun-native-plugin
Rustified wrapper for writing native plugins for Bun
-
bus_queue
Lock-free Bounded non-Blocking Pub-Sub Queue
-
thread_tryjoin
Try joining a thread
-
umpx
Collection of ump extensions
-
chorus_lib
Choreographic Programming in Rust
-
dutils
I am speed
-
may_waiter
coroutine communication blocker
-
halt
functionality for pausing, stopping, and resuming iterators, readers, and writers
-
augmented-atomics
Implements some extra types and utilities over atomics for building audio-thread / GUI synchronization
-
mcl_sched
installable wrapper for the MCL (Minos Compute Library) Scheduler 'mcl_sched'
-
taski
async task DAG execution
-
lendpool
lock-free library for allowing safe and concurrent access to a group of objects
-
ncd
Concurrency library
-
omp-gdk
Rust SDK for developing open.mp gamemodes
-
e2k
英単語から読みを推論するライブラリ(Patchethium/e2kのRust実装)
-
atomicoption
An atomic, nullable, owned pointer
-
threadpool-executor
A threadpool executor
-
rayon-cancel
An adapter to interrupt rayon parallel iterators
-
infinitree-backends
Embedded, encrypted database with tiered cache -- backends
-
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
-
simple-left-right
Lockfree, realtime safe and copy-free Synchronisation
-
ump
Micro message passing library for threads/tasks communication
-
parallel_worker
A parallel worker implementation in Rust. Allows to start tasks in parallel and receive the results blocking or non-blocking.
-
ferris-files
A CLI to find large files
-
global-channel
global channels
-
simpl_actor
tokio actors
-
hugealloc
Hugepage-aware allocator
-
crossbeam-deque
Concurrent work-stealing deque
-
quickwit-actors
Actor framework used in quickwit
-
moro
Experimental structured concurrency support for async Rust (similar to trio's nurseries)
-
mvsync
A standalone async and worker thread library, with expandable traits and command buffers
-
db
Lightweight high-performance pure-rust transactional embedded database
-
acto
light-weight Actor library for Rust
-
threadfin
A thread pool for running multiple tasks on a configurable group of threads
-
datacake
A batteries included framework for building fault-tolerance distributed data systems
-
zallocator
Amortizes the cost of small allocations by allocating memory in bigger chunks
-
flo_stream
Pubsub and related streams for Rust futures
-
re_smart_channel
A channel that keeps track of latency and queue length
-
goko
A lock-free, eventually consistent, concurrent covertree
-
parseq
Parallel sequential iterator
-
stylo_arc
A fork of std::sync::Arc with some extra functionality and without weak references
-
caos
Concurrent Append Only Segment-list
-
coroutine
in Rust
-
cuid1
CUID protocol in rust
-
conquer-once
Synchronization primitives for lazy and one-time initialization
-
grizzly_scheduler
A scheduler for running async tasks using cron expressions. It is built on top of tokio. Tasks can be parallel or sequential. Fuzzy random offset can be added to the cron expression.
-
mtlog
Multi-threaded logger with support for log files
-
thread_lake
A very high level thread pool manager
-
k-lock
A fast mutex for short critical sections
-
deque
A (mostly) lock-free concurrent work-stealing deque
-
dag-scheduler
a scheduler of dag computation graph
-
pi_async_graph
async graph
-
thread-object
Abstraction over thread-local storage allowing dynamic creation of TLS variables
-
pubserve
generic observer trait
-
moga
A multi-objective genetic algorithm framework
-
bicoro
Bidirectional co-routine data structures
-
nexus-actor-core-rs
Core library for Nexus Actor
-
arcu
An Rcu implementation using an Arc to keep the read critical section short and handle cleanup
-
treiber_stack
A lockless, thread-safe, atomic linked-list
-
diamond-types
The world's fastest text CRDT
-
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!)
-
apalis-core
Core for apalis: simple, extensible multithreaded background processing for Rust
-
packed-atomic
get any time access to atomic values
-
loates
load testing framework, with focus on ease of use and flexiblity
-
session_types
session types in Rust
-
spring-stream
Integrate sea-streamer with spring-rs
-
tokio-prometheus-metered-channel
Metered tokio channels with Prometheus metrics integration
-
thread_map
Types that are simple and easy-to-use alternatives to the
std::thread_local
macro -
rabbit_borough
Create a RabbitMQ consumer project with minimal effort, by bypassing templating, configuration and complicated resiliency logic
-
classic-sync
ReentrantLock, Semaphore and CyclicBarrier using Classic Linux Mutex systems
-
io-pipe
A fast and thread-safe library for creating multi-writer and single-reader pipelines in Rust
-
EMCompute
fast , simple and cross-platform parallel computing library
-
crosstalk
An extremely lightweight, topic-based, cross-thread, in-memory communication library
-
rayon-wasm
work-stealing parallelism for Rust
-
disrustor
This project is a port of the LMAX Disruptor to Rust
-
watch
A synchronous message passing channel that only retains the most recent value
-
antidote
Poison-free versions of the standard library Mutex and RwLock types
-
arc-cell
Helper for a simple Cell-like object containing Arc/Weak
-
rusty_junctions
Join Pattern implementation in Rust
-
lotsa
Execute lots of operations spread over any number of threads
-
xenevtchn
Rust bindings for Xen event channel API
-
crossbeam-skiplist-fd
A long-term maintained forked version of the crossbeam-skiplist for supporting more flexible key comparison customization
-
pulse
async wake signals
-
dfir_rs
DFIR runtime for Rust, used by Hydro
-
snarc
Sendable Non-Atomically Reference Counted
-
rcu_list
a lockless concurrent list implementation
-
leanify-many
spawn leanify subprocesses
-
sentinel-core
The flow sentinel of your microservices
-
alopt
providing efficient synchronization primitives that integrate Option into their design
-
hey_listen
An event-dispatcher-collection offering async, sync, parallel, and prioritised solutions!
-
mongo-lock-async
Distributed mutex locks with MongoDB
-
kademlia-dht
Kademlia DHT
-
del-cudarc
funcs for cudarc
-
sparking-lot-core
parking on addresses
-
leaklist
concurrent, lock-free, singly-linked list
-
easy-rs
reading and processing EEG and accelerometer data from .easy files
-
par-dfs
Parallel, serial, and async dfs and bfs traversal
-
fast-async-mutex
lib which provide asynchronous locking mechanisms (Mutex, RwLock, OrderedMutex and OrderedRwLock)
-
approximate
Scalable Approximate Counters
-
pawawwewism
a wewy sewious wibwawy fow stwuctuwed concuwwency, i pwomise :3
-
rearch-effects
Re-imagined approach to application design and architecture
-
fast-logger
Fast logger for Rust
-
deborrow
Splits mutable references safely into their fields, and helps with reference manipulation
-
pget
Used to solve the network instability issues encountered during large file downloads, supporting resumable downloads and concurrent downloads
-
atomic-waitgroup
A waitgroup implementation supports async with advanced features
-
ref_count
Efficient, low-level asynchronous synchronization for real-time and embedded systems
-
yash-executor
single-threaded concurrent task executor
-
thread-async
Execute a task in a new thread and await the result asynchronously
-
mqb
Lock free in memory message queue broker
-
rush_core
The rules engine is based on the rete algorithm
-
protoflow-flume
Protoflow implements flow-based programming (FBP) for Rust using Protocol Buffers messages
-
cache-padded
Prevent false sharing by padding and aligning to the length of a cache line
-
multithreading
in Rust
-
ring-channel
Bounded MPMC channel abstraction on top of a ring buffer
-
blackhole
...to throw your threads into
-
sharded_queue
ShardedQueue is currently the fastest concurrent collection which can be used under highest concurrency and load
-
workpool
Distribute work to a set of threads and wait for completion
-
readfish-tools
Tools for analysing adaptive sampling data
-
sea-streamer-socket
🌊 SeaStreamer backend-agnostic Socket API
-
either-slot
An atomic slot whose senders can either place their value into the slot, or retrive all the data from the slot
-
stronghold-stm
Software transactional memory
-
async-cpupool
async threadpool for CPU-bound tasks
-
tokio-etcd-lock
WIP
-
hopper
an unbounded mpsc with bounded memory
-
zkstate
Share a struct across multiple instances of an application using zookeeper
-
tagged-rendezvous
Rendezvous hashing with support for tag-based exclusions
-
ringbuf-blocking
Blocking version of ringbuf
-
rly
Run shell commands concurrently with ease. Currently only a CLI tool.
-
stakker_log
Logging support for Stakker
-
blaze-rs
A Rustified OpenCL Experience
-
xdrk
open XRK and DRK files, produced by AiM devices
-
xstream-util
A command line tool to split a stream to child processes
-
geph-nat
concurrent NAT thingy used throughout Geph
-
vlock
A fast and scalable multi-version shared state lock with wait-free read access
-
gpca
'Async Hyper-Graph Cellular Automata' computational model
-
keepcalm
shared types for multi-threaded programs
-
rust-lockless-slotmap
A (mostly) lockless slotmap implementation in Rust
-
evident
Pub/Sub library using IDs to identify events
-
single_value_channel
Concurrent single-value update and receive channel
-
discrab
Discord bot wrapper
-
protex
(Process Mutex) concurrency in process level
-
slacktor
extremely fast, bare-bones, low-overhead, supervisorless, no-std actor library
-
ptr_cell
Thread-safe cell based on atomic pointers
-
vigil
liveness checking watchdog for detecting deadlocks/livelocks/starvation etc
-
rgraph
A task graph library
-
yaks
Minimalistic framework for automatic multithreading of hecs via rayon
-
cooptex
Deadlock free Mutexes
-
ocl-interop
Creates an OpenCL Context with OpenGL Interop enabled
-
tc-scalar
TinyChain's scalar value enum, including concurrently-resolvable op definitions and references
-
simplelock
abstractions for inter-process synchronization
-
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
-
dpc-pariter
Parallel iterator processing
-
orx-concurrent-option
ConcurrentOption is a lock-free concurrent read and write option type
-
coarsetime
Time and duration crate optimized for speed
-
round_mult
A tiny library to round a number up or down to a multiplier
-
chute
Lockfree mpmc/spmc broadcast queue
-
conquerer
DAG analyzer for orchestrating concurrent code
-
portable-atomic-util
Synchronization primitives built with portable-atomic
-
command_history
managing command history in Rust applications
-
mogul
Agnosticly helps to manage concurrent versions of things
-
local-sync
Non-threadsafe data structure for async usage
-
oxidator
A reusable LMAX Disruptor Implementation in Rust
-
pikav
that help you send event to client with topic subscription
-
active_standby
A concurrency primitive for high concurrency reads
-
concurrent_lru
A concurrent LRU cache
-
gpgpu
WIP GPGPU framework built on top of wgpu
-
undead
search for dead code in your Python projects
-
atomicring
AtomicRingBuffer is a constant-size almost lock-free concurrent ring buffer
-
interruptible_polling
General purpose polling tasks with RAII-driven fast clean exits
-
parallely
command line process parallelization executor
-
ampsc
async multi-producer single-consumer channel
-
phazer
Two-phase commit for file creation
-
current_dir
Thread Safe Current Working Directory
-
big_data
Safe Rust code for creating Erlang NIF to store big data
-
context
Cooperative multitasking for Rust using Boost.Context
-
sea-streamer-redis
🌊 SeaStreamer Redis Backend
-
rtic-syntax
The Real-Time Interrupt-driven Concurrency (RTIC) meta language
-
ns3-parallel
A Multitask Parallel Concurrent Executor for ns-3 (network simulator)
-
omango-futex
Futex for Rust
-
lofi
Low Overhead Fibers
-
stuck
Multi-threading scheduled task facility building on cooperative stackful coroutine
-
evmap
A lock-free, eventually consistent, concurrent multi-value map
-
ductile
A channel implementation that allows both local in-memory channels and remote TCP-based channels with the same interface
-
real-time
Safely share data with a real-time thread
-
work-queue
A concurrent work-stealing queue for building schedulers
-
godwit-daemon
A daemon runner for GodWit
-
pargraph
Operator based parallel graph processing
-
terminate-thread
terminatable thread implemented with pthread
-
gaffer
Prioritised, parallel job scheduler with concurrent exclusion, job merging, recurring jobs and load limiting for lower priorities
-
quick_fetcher
Asynchronous HTTP file downloader with support for concurrency
-
tokio-condvar
A Condition Variable for Tokio Applications
-
currant
spawn concurrent shell processes in rust
-
semalock
concurrently writing to files in a safe and efficient manner
-
deploy
The
deploy
library to aide writing and debugging of distributed programs, as well as tooling to run them across a cluster -
hebo
Distributed MQTT broker
-
per-thread-mutex
Synchronization lock designed for wrapping thread-unsafe C libraries
-
gmtx
Mutex that grant exclusive access to a group of members
-
crossbeam-skiplist
A concurrent skip list
-
schedwalk
Test futures under all possible polling schedules
-
oncemutex
A mutex providing one-time synchronized access, then safe unsynchronized access
-
box-convert
convert
-
arcstr
A better reference-counted string type, with zero-cost (allocation-free) support for string literals, and reference counted substrings
-
topological_batch
Parallel running of topologically dependent units in batches
-
pcat
A dead-lock free parallel cat implementation
-
atomic-interval
A tiny implementation of an atomic timer
-
vin
An ergonomic actor framework
-
lock_pool
Robust, efficient, high performance, asynchronous object pooling
-
ordered-parallel-iterator
Performs tasks in parallel returning completed tasks in order of appearance
-
efflux
Easy MapReduce and Hadoop Streaming interfaces in Rust
-
asar-snes
Rust bindings for Asar (https://github.com/RPGHacker/asar)
-
fast-counter
A sharded concurrent counter
-
scoped-threadpool-std
scoped threadpool implementation and related tests including a password hasher
-
node-workers
A pool of long-lived nodejs workers
-
slb
Sharded load balancing text-streaming Unix tool
-
pime
Rust Python Integration Made Easy
-
left-right
A concurrency primitive for high concurrency reads over a single-writer data structure
-
mongo_sync
instant coding answers via the command line(just like howdoi)
-
io_partition
allowing to use just a part of a Read + Seek object
-
guest
By-value memory storage without by-value memory access
-
rpar
Run terminal command multiple times in parallel
-
tcb
A middleware service for delivering messages in a causal order
-
rtrb-basedrop
A fork of the
rtrb
crate that uses basedrop’s Shared pointer in place of Arc -
thread-counter
way of efficiently keeping track of active threads and waiting for them to exit
-
brutils
Some utilities for Rust
-
with_lock
Deadlock freedom
-
someday
Lock-free MVCC primitive
-
seckoo
A concurrent Cuckoo Hash Table
-
signals2
A thread-safe signal/slot library inspired by boost::signals2
-
cht
Lockfree resizeable concurrent hash table
-
async-datachannel
Async Wrapper for datachannel
-
dager
create and execute a graph of nodes
-
seda_bus
A Staged Event-Driven Architectural message bus
-
ratelimit_meter
A leaky-bucket-as-a-meter rate-limiting implementation in Rust
-
cpm-rs
Critical Path Method crate
-
nysa
A bus for passing messages around between independent subsystems of an application
-
tlid
Thread Local ID generator by predefined range without atomics/locks/random/time
-
wrrm
Write-rarely-read-many wrapper
-
RaceNG
Revolutionary, innovative, groundbreaking random number generator using race conditions
-
task-notify
Notify async tasks when someone mutates data they're interested in
-
ora-timer
Part of the Ora scheduler framework
-
mirror-common
A cross-platform screen casting library implemented by Rust
-
kioto-uring-executor
multi-threaded wrapper around tokio-uring
-
shared-expiry-get
concurrent async get with expiration for Rust
-
unknownrori-simple-thread-pool
A lighweight thread pool for networking and other stuff
-
mpmc
copy-pasted from old rust stdlib
-
bi
-
fslock-arti-fork
files as locks, forked for use in Arti
-
hammer-cli
Hammer is a no-config cli tool for running concurrent tasks with monorepo support
-
secc
Implements a Skip-Enabled Concurrent Channel (SECC) for Rust
-
job-pool
Thread Pool
-
msg_channel
message channel
-
para
A dataflow/pipeline parallelization framework
-
lagoon
A thread pool crate with an array of features
-
xrm
Cross Runtime Manager
-
periodically
running tasks on a schedule
-
netcon
A collections of tools and helper functions developed for and by NetCon Unternehmensberatung GmbH
-
naive-stm
Software transactional memory (STM)
-
remutex
Recursive mutex, adapted from Rust's standard library
-
lockfree
concurrent data structures and a solution to the ABA problem as an alternative of hazard pointers
-
zeet
Work-stealing thread pool built on crossbeam
-
ev_slotmap
A lock-free, eventually consistent, concurrent slot map
-
rs_lockfree
a lock-Free lib based on practical Hazard Pointers algorithm
-
executor-service
A fast and efficient Thread Pool like Java ExecutorService
-
relaxed
Wrappers around Atomics that always use
Ordering::Relaxed
-
parsli
Parallel status lines for Rust
-
hel-thread-pool
sync thread pool
-
stdworld
signal-safe std replacement
-
team
toolbox lib for fun
-
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…
-
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
-
autoincrement
wrapper for different purposes
-
amadeus-parquet
An Apache Parquet implementation in Rust
-
async-sema
Async semaphore library
-
riker
Easily build fast, highly concurrent and resilient applications. An Actor Framework for Rust.
-
employees
A small runtime that hides all the boilerplate when using threads
-
crusty
Fast && scalable Broad Web Crawler developed on top of crusty-core
-
native-timer
Timer library which uses OS timer capabilities
-
selfe-start
defining the entry point to the initial thread on seL4
-
promise_out
promiseOut version for rust
-
invocation-counter
Datastructure to answer to: how many times a function has been called in the last X minutes?
-
greenie
Green threads and coroutines in stable Rust
-
bustle
Benchmarking harness for concurrent key-value collections
-
lending_thread_pool
A thread pool where workers can lend their data to their tasks
-
bztree
BzTree implementation for Rust
-
concurrency-demo-benchmarks
A small utility to benchmark different approaches for building concurrent applications
-
namaste
-
managed-thread
Real fearless concurrency! Spawn threads that will be automatically destroyed when no longer needed
-
jtp
thread pool, similar to the ThreadPoolExecutor in java
-
try-mutex
Fast non-blocking mutex
-
proglog
Thread safe progress logging
-
pi_handler
A universal handler utils
-
fork-map
running operations in a child process spawned by
fork()
-
shrink_pool
A thread pool which agressively terminates its threads as soon as they are idle
-
refcapsule
Safely send references to other threads
-
entropy-ecs
一个虚拟世界
-
redbus
A high-performance global message bus for concurrent applications
-
aramid
Synthetic fibers
-
mpi-fork-fnsp
Message Passing Interface bindings for Rust (FORK)
-
evlru
An eventually consistent LRU designed for lock-free concurrent reads
-
dci
DCI-Closed, a frequent closed itemset mining algorithm, implemented in Rust
-
genzero
that lets you get the latest value of a type
-
weighted_rate_limiter
A weighted rate limiter
-
cnr
An operation-log based approach for data replication
-
jxl-threadpool
Internal crate of jxl-oxide to abstract over thread pool implementation
-
two_phase_channel
A safe synchronisation-free parallel communication channel by statically forbidding conflicting accesses
-
peril
Fast and safe Hazard pointers for Rust
-
laika
A namespace crate containing miscellaneous submodules (like an SPMC channel) of owner its-laika
-
tc-transact
Traits and locking utilities for a TinyChain transaction
-
base-threadpool
minimalistic threadpool implementation
-
awaitdrop
WaitGroup
-
reactivate
Thread Safe Reactive Data Structure. Made with ❤️ for 🦀
-
atomic-counter
Atomic (thread-safe) counters for Rust
-
swimming
Dive into Efficiency with Swimming: A High-Performance, No-Nonsense Connection Pool
-
reactivex
in Rust
-
multiqueue2
A fast mpmc broadcast queue
-
rattler_repodata_gateway
interact with Conda repodata
-
asc
Atomic Strong Count
-
rustler_elixir_fun
Call Elixir functions from NIFs implemented in Rust
-
async-named-locker
Lock implemented using future
-
thfmr-protocol
Internal control protocol encoding and decoding library for the TouHou.FM Radio project
-
kapot-executor
kapot Distributed Compute - Executor
-
unlock
Instrumented synchronization primitives helping you to unlock performance issues
-
atomic_mut
that facilitates atomic operations on arbitrary structs
-
libblobd-direct
blobd, direct variant
-
atomiq
Convenient tool for atomics in Rust
-
dycovec
A dynamically-allocated, concurrent vector
-
conquer-util
concurrent and lock-free programming
-
rustodrive
Rust bindings for controlling multiple ODrives with the CAN protocol
-
super_cell
A super (unsafe) cell that also implements send and sync regardless of the inner type's send/sync
-
fan
Simplifies fanning-out (and eventually -in) with channels
-
pakr-fsm
Template to implement finite-state-machines
-
norpc
Framework for in-process microservices
-
interval-task
Repeatedly execute a
Task
with fixed time delay. more thansetInterval
-
rtfm-syntax
The Real Time for The Masses (RTFM) meta language
-
persistent_stack
Concurrent persistent stack
-
timed-locks
Smart pointers to
tokio::sync
locks that either panic or error after a timeout -
channel-receiver
Channel Receiver
-
try-rwlock
Fast non-blocking readers-writer lock
-
rust-concurrent
Fast command line app in rust/tokio to run commands in parallel. Similar interface to GNU parallel or xargs.
-
tracing-mutex
Ensure deadlock-free mutexes by allocating in order, or else
-
object-pool
A thread-safe object pool with automatic return and attach/detach semantics
-
hubby
lock service
-
cond_sync
Hides the boilerplate code needed with std::sync::Condvar
-
dropout
Drop your objects out of main thread
-
supermon
A set of utilities for coordinating watchers, middleware, and consumers via channels
-
orx-concurrent-ordered-bag
An efficient, convenient and lightweight grow-only concurrent data structure allowing high performance and ordered concurrent collection
-
redsync
Redlock for distributed locks with Redis
-
eta_obj_pool
Thread safe object pool
-
graph
high-performant graph algorithms
-
lfchring
Concurrent, lock-free implementation of a consistent hashing ring data structure, supporting virtual nodes and keeping track of replication
-
oxidd-rules-zbdd
Zero-suppressed decision diagrams (ZBDDs) for OxiDD
-
idle
Collection of idle strategies to be used by thread(s) when they have no work to perform
-
left-right-cell
A cell with lock-free concurrent read access
-
distribuidos_sync
Sync common utils using standard library
-
scrummage
Fight over OS process prioritisation
-
shared-local-state
shared local state registry for use in EBR, IO, etc
-
ringbuf-basedrop
A fork of the
ringbuf
crate that uses basedrop’s Shared pointer in place of Arc -
spry
Resilient, self-healing async process hierarchies in the style of Erlang/OTP
-
reggie
fast Windows registry search tool
-
composure
Discord bot framework for running on the edge
-
local_thread
A local thread management library for Rust. No more 'static functions in order to start threads!
-
async-map-reduce
Fast map-reduce based on threading
-
takecell
A cell type which value can only be taken once
-
evolution
Efficiently evolve your old fixed-length data files into modern file formats
-
zolegus
-
simdvec
Vectors, but with the operational speedup of SIMD!
-
rayon-scan
A parallel prefix scan function for ParallelIterator
-
job_abstrs
Abstractions for event-driven jobs
-
pi_weight_task
任务池
-
xio_jobset
XIO jobset datatypes
-
forkjoin
A work stealing fork-join parallelism library for Rust
-
auto-ytdlp-rs
Download videos with yt-dlp automatically. You can even download multiple videos at the same time!
-
tc-tensor
TinyChain's Tensor collection type
-
noir-compute
Network of Operators In Rust
-
threadmap
WIP
-
usync
fast, drop-in, synchronization primitives
-
rsgc
Concurrent GC library for Rust
-
jobsys
Lockless Work Stealing Job System
-
hvm-core
massively parallel Interaction Combinator evaluator
-
priority-async-mutex
An async mutex where the lock operation takes a priority
-
lock_tree
Prevent deadlocks at compile time. A standalone republication of the netstack3 lock-ordering crate, part of Google's Fuchsia OS.
-
cell-family
Cheap cells accessed through unique owners
-
threads_pool
This package provides an easy way to create and manage thread pools, so you don't have to
-
mp2c
A multi producer multi polling consumer library that enables multiple producers to send messages to multiple consumers completely asynchronously
-
sync_splitter
Safely split a mutable slice in multiple threads at the same time
-
conqueue
multi-producer, single-consumer queue (MPSC)
-
hala-lockfree
Some lockfree structure for rust
-
cbloom
Concurrent implementation of Bloom filters
-
async-events
Waiting for external task completion in asynchronous Rust code
-
smartpool
A very customizable, future-aware threadpool
-
sesh
deadlock-free session-typed communication
-
hyperbridge
Fast multi-producer multi-consumer channel with async support
-
graph_csr
that provides utility functions for manipulating graphs in a CSR format, used as the baseline for constructing powerful graph algorithms
-
arrows
An actor framework in rust with message durability and ingestion order processing of of messages
-
threatpool
thread pool
-
unirun
Universal project runner
-
slave-pool
thread pool
-
atomx
Thread safe data structures based on atomic data types
-
threadalone
Make any value Send + Sync but only available on its original thread. Don't use on multi-threaded environments!
-
discord-termview
Spawn multiple concurrent unix terminals in Discord
-
run-them
A CLI to launch a single command with many workers, serializing the output
-
async-skipdb
An embedded, in-memory, zero-copy, atomicity, consistency, MVCC, almost lock-free and serializable snapshot isolation database engine
-
chashmap-async
Concurrent async hash maps with key-scoped locking
-
atomicbox
Safe atomic pointers to boxed data
-
slottle
A throttle pool library designed for thread-based concurrency
-
little_raft
The lightest distributed consensus library. Run your own replicated state machine!
-
denog_runtime
denog runtime library
-
cspice
Safe wrapper around the NAIF CSPICE toolkit
-
runloop
Cancelable non-blocking polling threads (with optional timeouts)
-
async-mutex
Async mutex
-
sleepfast
Sleep for very small amounts of time quickly
-
protoflow-syntax
Protoflow implements flow-based programming (FBP) for Rust using Protocol Buffers messages
-
locktree
Experimental compiler-checked deadlock-freedom
-
rayon-core
Core APIs for Rayon
-
testbench
Testing and benchmarking tools for concurrent Rust code
-
take-once
A thread-safe container for one-time storage and one-time consumption of a value
-
thread-group
std::thread::ThreadGroup prototype
-
idable
some sequence with no lock
-
threadbath
A minimal implementation of a thread pool
-
simt
compute support for rust
-
diplomatic-bag
A wrapper type that allows you to send
!Send
types to different threads -
thread-time
Small crate that provides CPU time measurement for threads
-
object-space
An object store library for highly concurrent program written in Rust
-
shared_resources
shared resources container which is thread-safe, and lock-free
-
verona-rt
Idiomatic binding to the verona runtime
-
crossbeam-epoch
Epoch-based garbage collection
-
shared-resource-pool-builder
Create thread pools with a shared resource
-
propresenter
Unofficial library for interacting with ProPresenter 7
-
overdose
Fast, Row Oriented, Kotlin, Scala-like dataframe
-
lockpool
offers a pool of locks where individual locks can be locked/unlocked by key
-
ulock-sys
Rust bindings for Darwin's (e.g. macOS, iOS, ...) not-entirely-public ulock API, which provides futex-like functionality.
-
response_channel
A bidirectional response channel
-
atomiclock
A non-blocking lock that can be used in async contexts
-
revenq
A concurrent, revision-based event queue implementation
-
twitch_api
talking with the new Twitch API aka. "Helix", EventSub and more!
-
arcow
Atomically Reference-counted Copy-On-Write shared pointer
-
killable_thread
A wrapper for thread that allows it to be easily stopped cooperatively
-
oxidater
A reusable LMAX Disruptor Implementation in Rust
-
pcp-mutex
A Priority Ceiling Protocol (PCP) mutex, based on Linux PI futex. Allows efficient and deadlock free execution.
-
tucan
fast, and multithreaded interner with loose type requirement
-
sever
Coerce hardlinks into new files
-
juliex
a very basic future executor
-
swapper
Swap ownership between threads
-
multithread
API for data-parallel tasks, rayon-lite
-
status_executor
Run your work on some context (thread) and get status info back
-
fenic
test concurrent code
-
ditto
CRDTs for common data structures like maps, sets, vecs, strings, and JSON
-
synqueue
Internally synchronized (MPMC) queue
-
reactor_rs
reactor-rust is an implementation of the Reactive-Streams
-
turbolift
Easy distribution interface 🚡
-
atomic_prim_traits
Traits over primitive atomic types
-
yastl
scoped threadpool library
-
piper
Async pipes, channels, mutexes, and more
-
foco
Topic-based strongly typed pubsub for no_std rust
-
stoppable_thread
A wrapper for thread that allows it to be easily stopped cooperatively
-
poolter
Thread Pool implementation for Rust using JavaScript Promise like functional syntax
-
async-spin-sleep
providing a highly accurate asynchronous timer for multiple async tasks using spin sleep in a single thread
-
maxwell-utils
Maxwell utils implementation for Rust
-
tasque
thread pool library
-
double_decker
unbounded multi-producer multi-subscriber event bus built with crossbeam channels
-
licensebat-core
Types and Traits for building Licensebat libraries
-
queue-ext
The extended feature of the queue can convert the pop() function of the queue to Stream and the push() function to Sender
-
parallel_reader
reading from a file (or any
Read
stream) and processing it by chunks, in parallel -
concurrent-round-robin
A concurrent wrr implementation for rust
-
crossbeam-skiplist_piedb
A concurrent skip list
-
range-lock
Range lock for std::vec::Vec
-
synevi_network
A leaderless, consensus library based on Apache Cassandra's Accord algorithm
-
ei-sys
Low level Rust bindings to ei, a library to communicate with distributed Erlang
-
cpu-affinity
Cross-Platform CPU affinity
-
dynamic_ocl
Dynamically-loaded OpenCL bindings
-
ipmpsc
Inter-process Multiple Producer, Single Consumer Channels
-
crb-core
CRB | Composable Runtime Blocks | Core
-
balter-runtime
A load/stress testing framework
-
specs-static
extension for Specs that adds custom ids
-
melodium-common
Common Mélodium elements and traits
-
sas
Salty-and-Sweet one-line Rust Runtime Performance Optimization Library
-
jobsteal
A work-stealing fork-join threadpool written in Rust
-
hwlocality
Idiomatic Rust bindings for the hwloc hardware locality library
-
mscheduler
Use mongodb to schedule task running
-
conveyor_belt
Queue and batch processing library
-
peace-lock
A zero-cost abstraction lock that helps check contention free algorithms
-
amadeus-serde
Harmonious distributed data analysis in Rust
-
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)…
-
std-semaphore
A counting, blocking sempahore extracted from rust 1.7.0
-
pb-atomic-hash-map
An atomic hash map
-
kcas
A lock-free, allocation-free multi-word compare-and-swap library
-
one_for_one
supervize spawn'ed async tasks
-
stop-thread
Various ways of stopping threads on various platforms, without requiring the thread to poll
-
threadstack
A more ergonomic and more flexible form of thread local storage
-
asparit
Async Parallel Iterators for Rust
-
rt-watchdog
Real-time userspace watchdog for Rust
-
spin-lock
spin lock implemented by the standard facilities
-
chunklist
A Chunk List is a new, concurrent, chunk-based data structure that is easily modifiable and allows for fast runtime operations
-
sea-streamer-file
🌊 SeaStreamer File Backend
-
stm
Software transactional memory. Allows composable atomic operations.
-
statman
Stat Manager
-
abyss-promise
[abyss] A simple promise implementation with adaptive threadpool support
-
ligmars
Safe bindings to the LGMP C library
-
debugit
Debug-print any value without trait bounds using specialization (Rust nightly channel)
-
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… -
ump-ng
Micro message passing library for threads/tasks communication
-
hv-guarded-borrow
Traits and implementations for generic use of "guarded" borrows
-
pinboard
A lock-free, threadsafe way to publish data, just stick it on the pinboard
-
dlopen2
opening and operating on dynamic link libraries (also known as shared objects or shared libraries)
-
mtlog-progress
A progress bar implementation working gracefully with mtlog's logger
-
carpet
A thread-safe, fully-parallel directed graph
-
ump-ngx
Collection of ump-ng extensions
-
electrologica
High performance concurrent primitives for Rust
-
nvrtc
Bindings for NVIDIA® CUDA™ NVRTC in Rust
-
stronghold-rlu
Read-Log-Update software transactional memory like synchronization mechanism
-
fast-walker
Multi-threaded directory walker, with async support
-
grandma
A lock-free, eventually consistent, concurrent covertree
-
datacake-crdt
A conflict free replicated datatype based on a hybrid logical clock implementation for building eventually consistent data stores
-
shardize
proc macro that generates code to create a sharded form of an existing container
-
spin_loop
-
scx_rustland_core
Framework to implement sched_ext schedulers running in user space
-
maybe-sync
Helper crate for libraries that want to have a switch between multi- and single-threaded versions
-
governor
A rate-limiting implementation in Rust
-
task_log
Task based logging
-
singleflight
port of Go's singleflight package for call collapsing
-
refptr
Inherently reference counted structs
-
pflock
A phase-fair reader-writer lock that reduces worst-case blocking for readers. Especially useful for multiprocessor real-time systems.
-
queuingtask
queueingtask is a library for running different threads in order in Rust
-
streambed-patterns
Patterns for working with streambed
-
caring
Sharing is caring: a safe library for mmap'ing memory in multiple processes
-
atomic-try-update
Primitives that make it easy to implement correct lock-free algorithms
-
nexus-acto-rs
Actors
-
blobd
Blob storage designed for huge amounts of random reads and small objects with constant latency
-
async-liveliness-monitor
A Liveliness Monitor for your Asynchronous Runtimes
-
tyra
Typed Actor System
-
acteur
A safe actor-like framework that just works. Simple, robust, fast, documented.
-
mbarc-map
Minimally-blocking, Atomic Reference Counted Map
-
atomic-memcpy
Byte-wise atomic memcpy
-
spliter
way to implement Rayon's ParallelIterator
-
flue
An efficient and secure actor runtime library
-
shared_cell
Interior mutability between concurrent tasks on the same thread
-
rayon_iter_concurrent_limit
Limit the concurrency of an individual rayon parallel iterator method with a convenient macro
-
sched-callback
async callback scheduling
-
paragraphs
A Parallel Graph Execution Library
-
chashmap
Fast, concurrent hash maps with extensive API
-
zestors
A fast and flexible actor-framework for building fault-tolerant Rust applications
-
amadeus-types
Harmonious distributed data analysis in Rust
-
atomicslice
thread-safe shared slices that are just about as fast as possible to read while also being writable
-
atomicdouble
128-bit atomics for generic type
-
tinypool
thread pool implementation in Rust
-
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.
-
gosh-remote
Distributed parallel computing over multiple nodes
-
incr
fast and self-contained data structures for checking whether a new value is greater than the previous maximum
-
barriers
A barrier spin lock implementation
-
hj_thread_pool
thread pool implementation in Rust
-
squeue
sized queue
-
maybe_parallel_iterator
Toggle parallelism with feature flags!
-
sync_2
A little crate providing a Rust implemented Mutex and RwLock
-
crossbeam-skiplist-pr1132
A concurrent skip list
-
channel-sender
Channel Sender
-
rt-history
An RT-safe history log with error checking
-
killswitch_std
A thread-safe kill switch using only the standard library
-
lazy_id
A thread-safe lazily-initialized ID
-
todc-utils
building and testing distributed systems
-
consumable_vec
generic approach to create a mutual database for multiple producers and consumers
-
atomic_box
A struct which allows multiple threads to safely update and read from a shared non-nullable pointer to heap data
-
ofilter
fast thread-safe Bloom filter
-
chashmap-serde
Fast, concurrent hash maps with extensive API and Serde support
-
moka
A fast and concurrent cache library inspired by Java Caffeine
-
fast-threadpool
Thread-pool implementation optimized to minimize latency
-
arrow-rayon
Use parallel iterators for Apache Arrow with rayon
-
fenris-paradis
Parallel processing of disjoint indices for the fenris library
-
batch-lock
A lock manager with batch-lock support
-
rusted_pipe
Real time processing library for developing multithreaded ML pipelines, written in Rust
-
thread-control
control threads' execution/status
-
base-coroutine
A fast and safe implementation of stackful coroutines with scheduler which supports preemptive scheduling
-
xloc
A fast, multi-threaded line counting utility written in Rust
-
skipchannel
skipchannels allow to communicate between threads, but always skip to the last sent value
-
consume
Memory order consume for when it's known that the compiler can't elide the dependency
-
tsuki-scheduler
light wight, composable and extensible scheduler for every runtime
-
sea-streamer-examples
🌊 The stream processing toolkit for Rust
-
colosseum
A variety of arena allocators for Rust, including thread-safe arenas
-
async-datachannel-wasm
Async Wrapper for WebRTC datachannel in the browser environment
-
typed_shmem
Typed shared memory crate for *nix and Windows
-
box-counter
counter
-
web_worker
implementing web workers to run rayon-styled concurrent work on wasm
-
acto-rs
Experimental actor library, under development. (renamed from minions_rs).
-
bastion-executor
Cache affine NUMA-aware executor for Rust
-
mlsp
small library for smart pointers that use both thread local and global atomic counters
-
talaria
A high performance, cyclic message passing library
-
rayon_logs
Traces for the rayon work-stealing library
-
bmrng
async MPSC request-response channel for Tokio
-
send-cell
Immutable memory region with runtime Send checking
-
twinsies
Smart pointer providing 2-way joint ownership of an object
-
priomutex
A mutex where waiting threads specify a priority
-
channel_io
Reader implementation on channel of bytes
-
lossyq
concurrent single publisher, single consumer queue with fixed length, that never blocks the writer
-
quartz_sched
Minimalistic scheduling library for Rust
-
RobotS
Actor framework
-
rattler_lock
Rust data types for conda lock
-
mpmcpq
Multi-producer multi-consumer Priority Queue
-
geese_pool
Message-passing system for networking with Geese
-
inert
lets you use non-Sync values in a Sync way
-
paradis-demo
demo functionality for paradis, not intended for use
-
rcurs
An oxidized RCU implementation
-
swap_channel
A safe lock-free parallel communication channel based on mem::swap
-
agent_rt
agent scheduling
-
structured-spawn
Structured async spawn implementations for Tokio
-
hv-lease-tracker
no-std compatible tracking of borrow origins, for providing better diagnostics when implementing interior mutability primitives
-
structured_persistent_logger
A structured 'log' logger that allows for persistent fields
-
scrappy_do
A concurrent asynchronous webscraping framework
-
fused-reader
fused reader type that if writer thread dies while holding armed fuse the reader will get BrokenPipe error
-
coro
Stackful, first-class asymmetric coroutines
-
cpq
A Concurrent Priority Queue implemented in Safe Rust
-
dekker
Dekker's algorithm for mutual exclusion
-
option-lock
mutex for Option values
-
zkmq
Message Queue, backed by Zookeeper
-
spinning
Mutexes and SIX locks implemented by spinning
-
sentinel-rocket
Sentinel middleware for Rocket
-
fiona
Concurrent runtime written against liburing
-
wasm_sync
Synchronization primitives for both web and native
-
onetime
(aka. oneshot) async spsc channel
-
blinkcast
Fast, bounded, multiple-producer, multiple-consumer, lossy, broadcast channel
-
threadpool-crossbeam-channel
A fork of the threadpool create, which uses crossbeam-channel instead of std::mpsc
-
uf_rush
A lock-free, thread-safe implementation of the Union-Find (Disjoint-Set) data structure
-
protoflow-blocks
Protoflow implements flow-based programming (FBP) for Rust using Protocol Buffers messages
-
rsevents-extra
Synchronization objects built on top of rsevents. Semaphore, countdown event, and more.
-
sync_select
A short-circuiting (verbose)
std::thread::scope
-
atomic_pingpong
Lightweight no_std ping-pong buffer, using AtomicU8 for synchronization
-
blacksmith
Building-block functions for async systems
-
aktors
Driver for derive-aktor
-
operator-framework
Tools and helpers used to create Kubernetes operators
-
tc-server
TinyChain's cluster server logic, including peer discovery and replication
-
nolock
A collection of Lock-Free Datastructures
-
uchan
Multi-producer single-consumer channel for message passing
-
shared_memory
A user friendly crate that allows you to share memory between processes
-
rdispatcher
Dispatcher for Rust, broadcast and subscribe many to many
-
libmcs
A MCS Lock Library
-
ark-secret-scalar
Secret scalars for non-constant-time fields and curves
-
threadpool-simple
Threadpool for working with many tasks easily
-
cloudi
API
-
genserver
Elixir inspired async actor library
-
bombs
Efficient single-producer multi-consumer channel types
-
txn
A generic optimistic transaction manger, which is ACID, concurrent with SSI (Serializable Snapshot Isolation)
-
threadbeam
specialized channel type for beaming data out of a newly spawned thread
-
one_at_a_time_please
For serialising calls to functions
-
easy-parallel
Run closures in parallel
-
television
A cross-platform, fast and extensible general purpose fuzzy finder TUI
-
swimming-pool
threadpool for running a number of jobs on a fixed number of threads
-
select-macro
Waits on multiple concurrent branches
-
terminate
abstract logic to terminate threads, coroutines and the like
-
lockfree-ringbuffer
A lock-free ring buffer implementation in Rust
-
go-spawn
that provides macros to spawn and join threads with minimal boilerplate
-
work-steal-queue
Concurrent work-stealing queue, implemented using st3 and crossbeam-deque
-
bplustree
Concurrent in-memory B+ Tree featuring optimistic lock coupling
-
laststage
fast, durable, high concurrent HashMap
-
parallel-iterator
Parallelize any iterator with ease!
-
atomic-borrow
atomic reference counter
-
rtfm-core
Core abstractions of the Real Time For the Masses framework
-
ora-worker
Part of the Ora scheduler framework
-
bursty
Test support for exarcebating contention in multi-threaded code
-
semaphore-key
control concurrent thread access by key using a shared semaphore
-
threadsafe_zmq
Threadsafe zeromq
-
ctx-thread
Cooperative, scoped threads based on crossbeam and golang’s context package
-
mini-io-queue
Fixed-length, allocation and lock-free, async I/O oriented single-producer single-consumer queues
-
atomic-destroy
An value which can be atomically read and destroyed; like an atomic Option
-
update_channel
A channel for single updatable values
-
contrie
Concurrent map and set
-
quick_cache
Lightweight and high performance concurrent cache
-
rjq
Redis job queue
-
gex_sys_build_parse_mak
Parse mak file to build gex-sys
-
parallel-event-emitter
Parallel Event Emitter for concurrent listener invocation based on futures-rs and futures-cpupool
-
once_mut
Safe mutable reference to static variable that can be obtained only once
-
sync-wait-group
Wait group for synchronizing the beginning or end of some computation
-
humthreads
Threads for humans
-
threadgroup
Manage groups of threads as one unit, join the first one that finishes, timeout on join attempts
-
semrs
A pure rust implementation of semaphores
-
mth_calc
demonstrating Cargo. Contains helper method for running a process in parallel on all available processors.
-
rayon_croissant
<lqd> bikeshedding the name: something that is mapped folded and collected, a 🥐
-
parking_lot_rt
Parking-lot fork for real-time applications
-
atomic-hyperloglog
thread-safe hyperloglog, with atomics
-
hv-elastic
Safe and almost-safe abstractions for lengthening lifetimes and
'static
“loaning” of non-'static
types -
async-priority-channel
An async channel where pending messages are delivered in order of priority
-
pacwrap-core
providing core functionality for pacwrap
-
nettu_scheduler_api_structs
Nettu scheduler api types
-
fslock
files as locks
-
witty-actors
Fork of quickwit-actors, Actor framework used in quickwit
-
affinity
consistent way to set core affinity for currently running threads and processes
-
clustr
Multithreaded string clustering
-
rcell
A Cell which can hold either an Arc or an Weak smartpointer or be empty
-
yaambo
concurrent skip lists
-
mrsc
mpsc with requests
-
bevy_gpu_compute_core
Empowering anyone to leverage GPU-acceleration with as little barrier-to-entry as possible
-
rayoff
rayon but it's map-reduce
-
tenorite
A concurrency abstraction library. Provides a client-server model for asynchronous workers
-
sea-streamer-runtime
🌊 SeaStreamer async runtime abstraction
-
ump-ng-server
Server message dispatch loop for ump-ng
-
gemino
A multi producer multi consumer (MPMC) broadcasting channel
-
stewart
A minimalist, high-performance, and non-exclusive actor system
-
open-coroutine-queue
Concurrent work-stealing queue, implemented using st3 and crossbeam-deque
-
unbounded-spsc
An unbounded spsc queue built from
bounded_spsc_queue
s -
ppipe
An elegantly simple and lightweight library for making iterator pipelines concurrent and blazingly fast, hence the name ppipe (parallel pipe)
-
scoped-pool
A flexible thread pool providing scoped threads
-
key-message-channel
Multi-producer single-consumer queue capable of queuing messages by message key
-
swap-arc
A swappable Arc
-
rusty-variation
deadlock-free session-typed communication
-
rustpool
A data and thread pool library for Rust
-
mrogalski-looper
Clean abstraction for a single-threaded event loop. Built as a lightweight wrapper around the std::sync::mpsc package.
-
thread_isolated
Isolating values allowing access via closures run on an owning thread
-
objectpool
lock-free object pool, support no_std
-
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.
-
slog-json-concur
JSON drain for slog-rs with concurrency
-
quinine
Atomic monotonic containers (Mono{Box,Arc})
-
hadron-client
The Hadron Rust client library
-
readahead-iterator
Readahead from an iterator on a separate thread, returning items in order and synchronously
-
more-sync
More synchronization utils
-
ste
A single-threaded executor with some tricks up its sleeve
-
agner-actors
An actor toolkit inspired by Erlang/OTP (actors)
-
linux-rtic
A Real-Time Interrupt-driven Concurrency (RTIC) implementation for Linux
-
llq
Wait-free SPSC linked-list queue with individually reusable nodes
-
dynqueue
Dynamically extendable Rayon parallel iterator
-
lines-rs
⚡ A fast line counter written in rust
-
mtxgroup
mutex group locks all mutexes at the same time
-
shareable
Thread shareable objects using the minimal amount of synchronization
-
spsc-buffer
Single-producer single-consumer lock-free buffer
-
jthread
Deadlock-free Mutual Exclusion locks for Rust
-
context-coroutine
set of extensions to provide stackful coroutines; it is not officially associated with the context crate
-
cogo
Rust Coroutine Library like go
-
slock
An async mutex that never deadlocks
-
rustc-rayon-core
Core APIs for Rayon - fork for rustc
-
npnc
Lock-free queues
-
mqtt_actor
An mqtt adapters (from port and adapters) to be used with actix actors
-
amadeus-aws
Harmonious distributed data analysis in Rust
-
semanticsimilarity_rs
designed to compute similarity/distance metrics between embeddings
-
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. -
gts-transport
Gts transport
-
stretto
high performance thread-safe memory-bound Rust cache
-
waithandle
that makes signaling between threads a bit more ergonomic
-
my_threadpool
threadpool
-
thread-owned-lock
Mutex which can only be unlocked by the owning thread
-
atomiclock_async
async lock
-
double-checked-cell-async
A thread-safe lazily initialized cell using double-checked locking
-
skippy-rs
A set of lock free, thread safe, and fast data structures implemented via a Skip List
-
bndpresbufch
Bounds-preserving channel for passing buffers
-
uppercut
Small and simple actor model implementation
-
taskqueue
Parallel execution of the task queue with the ability to add new tasks inside the running tasks
-
amadeus-commoncrawl
Harmonious distributed data analysis in Rust
-
firefly
[EXPERIMENTAL]
-
user-sync
user-space synchronization
-
cupchan
async overwriting channel between two threads that is wait & block free by swapping cups around
-
critical-section
Cross-platform critical section
-
srmap
A lock-free, eventually consistent, concurrent multi-value map
-
spinout
A thread-safe clonable and mutable smart-pointer akin to
Arc<Mutex<T>>
, using spin-lock instead of system futex -
csplib
CSP for concurrent programming
-
atomicbox_nostd
Fork of the atomicbox library that works in no_std contexts
-
ocl
OpenCL bindings and interfaces for Rust
-
async-unsync
asynchronous, unsynchronized (thread-local) channels and semaphores
-
tokio-par-stream
parallel streams powered by tokio
-
thunk
Primitives for generic lazy evaluation in Rust. This crate requires nightly for
untagged_unions
. -
fibril
implementing distributed systems with commmunicating fibers
-
evelyn
event distribution library
-
melodium-engine
Mélodium core engine and executor implementation
-
triex
Trivial Executor
-
pipeliner
nice interface for parallel programming with iterators
-
cocoro
A more type-safe take on Rust stackless coroutines
-
blocking_semaphore
performant blocking semaphore
-
async_ach-waker
Async Atomic Channel
-
momen
low overhead thread pool
-
striped-lock
Striped Lock for Rust
-
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
-
rpools
A minimalist workerpool for rust
-
malobu
Atomic MPMC Bus
-
monotone
counters and queues for coordination in distributed systems
-
tiny-actor
A minimal actor framework for Rust
-
redis-queue-rs
Redis Queue with sync and async support for Rust
-
a_r_c_h_e_r_y
TEMPORARY CRATE
-
syncell
Sync alternative to RefCell
-
sortlock
providing ordered locking
-
lightproc
Lightweight process abstraction for Rust
-
ach
Atomic Channel
-
raliguard
Lazy rate limit semaphore implementation for your asynchronous code frequency execution
-
sea-streamer-types
🌊 SeaStreamer Traits & Types
-
read-write-api
interface to unify single-threaded code and RwLocks-based code
-
minicoroutine
mini coroutine library in rust
-
poolio
A thread-pool
-
locker
named mutex/locker for rust-lang concurrency
-
concurrency_traits
Traits for concurrent primitives
-
threadpooled
Threadpool implementation
-
rutin_dashmap
Blazing fast concurrent HashMap for Rust
-
bichannel
Zero dependency std::mpsc based bidirectional channel
-
sentinel-actix
Sentinel middleware for Actix-Web
-
shared_channel
Multi-producer, multi-consumer FIFO queue communication primitives
-
steelmill
A resource manager (dependency injector / factory) designed for distributed systems and simulation testing
-
threads
Traits to abstract thread-pools
-
sync-cell
A collection of easier to use thread-safe types for the creation of larger thread safe systems
-
spawns-compat
Async runtime detections for thread context task spawner
-
read-write-store
A concurrent, unordered collection for Rust, where each element has an internally generated ID and a read-write lock
-
queued-task
concurrent queue task processing
-
af-opencl-interop
ArrayFire is a high performance software library for parallel computing with an easy-to-use API. This crate is an addition on top of ArrayFire crate to enable users to mix RAW CUDA code in rust and ArrayFire.
-
atomiclock_spinlock
spinlock
-
chunker
Minimalistic parallel executor
-
workctl
number of higher-level control mechanisms for concurrent work scheduling, built on standard library concurrency primatives
-
todc-mem
Algorithms for shared-memory distributed systems
-
spsc-bip-buffer
A concurrent, spsc ring-buffer with sized reservations
-
syncmap
fast, concurrent cache library built with a focus on performance and correctness. The motivation to build syncmap comes from the sync.Map in Golang
-
concache
A fast, concurrent, shared hash map
-
toktor
A small tokio-based Actor framework
-
periodic_do
Run task periodically until it reaches a terminal state
-
roundabout
An message oriented concurrent runtime
-
coroutines
High performance coroutine library with native experience
-
scx_p2dq
pick two load balancing scheduler in BPF
-
highroller
high-level rolling index that is thread-safe and guarantees cheap runtime-unique IDs
-
ticketed_lock
Ticketed lock system - allows one to separate lock request from the actual waiting
-
broker-tokio
tokio for broker
-
worker-pool
handle a set of worker threads, which need to communicate back their result to the main thread
-
rider
bounded executor for tokio; limit the count of tasks running 🚦
-
clone-replace
Share mutable data by cloning and replacing a reference version
-
sorted-channel
sorted message-based communication channel
-
rayon-par-bridge
Process Rayon parallel processing with a traditional sequential Iterator
-
threadcell
A cell whose value can only be accessed by a owning thread
-
essential-lock
A minimal crate containing Essential's locking method that is safe to use in async code
-
spawns-executor
Async executors for thread context task spawner
-
polyester
Parallel iterator adaptors that accept arbitrary iterators
-
ping-pong-cell
An atomic cell for up to two threads
-
namedlock
Namespaces for named locks
-
fibril_verifier
Verifies behavior for distributed systems implemented with the Fibril library
-
pipelines
constructing multi-threaded pipelines of execution
-
microlock
waiting: Small locks and other timing things!
-
bufchan
buffered MPSC channel
-
observable-btree
Reactive Observable BTree
-
fugue-mptp
A generic multi-process task processor
-
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 -
rs_taskflow
executing graphs of tasks
-
closure-future
Easily run closures on thread pools and turn their result into Futures
-
glock
Granular locking crate for Rust
-
tange
Scalable Task-based Parallelism Framework
-
melodium-lang
Mélodium language parsing and semantic analyser
-
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.
-
bounded-spsc-queue
A bounded SPSC queue
-
faucet
Back-pressured MPMC queue that can be drained after signaling completion
-
copepod
An instrumentation tool to monitor queue depths in tokio channels
-
global_counter
Global, thread-safe counters
-
employer
Spawn worker threads and check on them later
-
fuze
A mechanism to wait for a single signal which can be checked at any time
-
rslint_rowan
threadsafe fork of rowan for the rslint project
-
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.
-
hv-cell
A no-std port of the
atomic_refcell
crate with additionalArc
-centric functionality -
tokio-bichannel
Bidirectional tokio::sync::mpsc channel
-
mutex_logger
logger that usess mutex for thread safty
-
movie
An actor / thread orchestration library / macro / framework
-
or_poisoned
Unwrap std lock guards in a semantic way
-
arbalest
Like Arc<T> but where weak references don't forbid mutable access
-
wei-scheduler
wei scheduler
-
sharded-slab
A lock-free concurrent slab
-
bondi
Single producer, multi consumer lock-free ring buffer (experimental)
-
c-map
Very fast concurrent hashmap
-
simple-rw-global
GlobalContainer based on std::sync::RwLock
-
ordered-locks
Compiletime deadlock avoidance
-
par-map
Parallel map and flat_map
-
rayon-tlsctx
thread local contexts for rayon loops
-
chex
Global exit signal library
-
gothack-future-parking_lot
An "as simple as possible" Future implementation for parking_lot
-
rapidsync
Rapid & threadsafe embedded data stores
-
crabflow
Task orchestrator
-
rolock
Read Only Lock
-
mwmr
A generic optimistic transaction manger, which is ACID, concurrent with SSI (Serializable Snapshot Isolation)
-
fencing
tokens
-
pool_barrier
A barrier for blocking a main thread until the completion of work which has been offloaded to worker threads, without blocking the worker threads
-
lariv
Linked Atomic Random Insert Vector: a thread-safe, self-memory-managed vector with no guaranteed sequential insert
-
atomic-bus
Atomic MPMC Bus
-
theatre
A concise async actor model implementation
-
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.
-
paradis-core
core functionality for paradis
-
ora-api
Part of the Ora scheduler framework
-
sling
Sequentially lockign (SeqLock) Ring Buffer
-
waitcell
A cell type containing a value which may not yet be available
-
bi_channel
Manage bidirectional mpsc channels more conveniently
-
init_guard
A Synchronization Primitive for guarding against double initialization
-
riffy
An unbounded, wait-free, multi-producer-single-consumer queue
-
callback_cell
Like an Atomic<Option<Box<FnOnce()>>>
-
proc-lock
cross-process locking API
-
infinitree-macros
Embedded, encrypted database with tiered cache
-
run-down
protection in rust
-
arl
A rate limiter to be used with tokio
-
open-coroutine-iouring
The io_uring support for open-coroutine
-
meslin
Ergonomic messaging for Rust
-
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.
-
busan
An actor implementation for Rust
-
dashmap_with_out_t_map_trait
Blazing fast concurrent HashMap for Rust
-
stoplight
stoppable tasks/threads
-
mycorrh
fast concurrent messaging system for Rust
-
lazy_ref
Implements a non-blocking synchronization primitive for lazy-initialized immutable references
-
membarrier
Process-wide memory barrier
-
rendezvous_swap
Swap data and sync execution between a pair of threads efficiently
-
async-once-watch
Asynchronous and shareable container which value is set once
-
atomic_immut
Atomic immutable value
-
sync_cow
Thread-safe clone-on-write container for fast concurrent writing and reading
-
kik_sync_service
A synchronous threading worker channel for generating the results you want with the data you need
-
shared-mutex
A RwLock that can be used with a Condvar
-
concurrent-initializer
concurrent initializer to ensure initialization only once per key
-
rcu_128
RCU (Read-Copy-Update) implementation for platforms supporting atomic 128-bit operations
-
jobpool
lightweight threadpool implementation
-
scheduling
job scheduler
-
rarena-allocator
Lock-free ARENA allocator which can be used in both memory and on-disk
-
threadling
Threads as traits
-
waitable
A synchronized (atomic) value container implementing the Mutex+Condvar pattern for efficient blocking waits
-
async_ach-notify
Async Atomic Channel
-
mpmc-map
Mpmc async map implementation for highly concurrent low-write access
-
spms_ring
Single publisher, multiple subscriber ring buffer for pubsub
-
hyaline-smr
Garbage Collector(Hyaline- Safe Memory Reclaimation) for lock free data structures
-
optimistic-cell
lock-like structure for low-overhead optimistic concurrency
-
workers_pool
A long running threadpool for parallel task execution
-
fixed_ring_buffer
An asynchronous SPSC fixed-capacity look-free ring buffer, which can be used to transfer data between two threads or between two asynchronous tasks
-
thread_db
Rust wrapper for libthread_db
-
liblightning
High-performance general-purpose stackful coroutine library
-
concurrency_toolkit
Easy switching between std::sync, tokio::sync and loom::sync
-
mwcas
Multi-word CAS primitive
-
rtic-common
lib TODO
-
atomic-story
An brief overview of atomics and memory ordering on a multi-threaded context with examples
-
hurdles
Counter-based thread barrier
-
kiss-icp-runtime
Unofficial Pure Rust Implementation of kiss-icp
-
open-coroutine-core
The open-coroutine is a simple, efficient and generic coroutine library
-
kai-cli
Kai - todo.txt task scheduler
-
portable-atomic
Portable atomic types including support for 128-bit atomics, atomic float, etc
-
agner-sup
An actor toolkit inspired by Erlang/OTP (supervisors)
-
hv-atom
Convenient abstractions for atomic operations on smart pointer/reference types, based on the
atom
crate -
sento
A lock-free, append-only atomic pool
-
access-queue
limit the number of simultaneous accesses to a value
-
derivable-object-pool
A thread-safe derivable object pool collection with automatic reusage of objects
-
tokio-sync-read-stream
Create a stream from a std::io::Read using Tokio blocking threads
-
promissory
One-shot value exhange between threads
-
rustix-futex-sync
Linux futex-based synchronization
-
balter-core
A load/stress testing framework
-
mtlog-tokio
Scoped logging for tokio runtimes with support for log files
-
hytra
Datastructure for fast multi-threaded updates
-
thread_reviver
A Discord bot to revive any archived threads (to counter Discord's auto-archive function)
-
work_pool
work queue wrapped by a thread pool
-
storage-map
Concurrent append-only map storage
-
pmpmc
A priority multi producer multi consumer channel
-
mula
Share expensive computation with various requesters
-
mpmc-scheduler
multi-mpmc, cancellable, scheduler with rate limiting
-
parking_monitor
Parking-lot-flavored monitor synchronization construct
-
dynpool
A thread manager that is lightweight, flexible, and rescalable
-
bbq-rs
A Block-based Bounded Queue for Exchanging Data and Profiling
-
datacake-node
The core cluster membership system built ontop of Quickwit's chitchat
-
ump-server
Server message dispatch loop for ump
-
axka-rcu
A reference-counted read-copy-update (RCU) primitive used for protecting shared data
-
datacake-rpc
A zero-copy, actor-like RPC framework using rkyv
-
mutex-timeouts
let you specify a timeout on a mutex lock
-
rayon-core-wasm
Core APIs for Rayon
-
ice-threads
Lightweight Thread pool implementation
-
dynamic-pool
a lock-free, thread-safe, dynamically-sized object pool
-
mpmc-ringbuf
queue
-
rust-debugging-locks
debugging locks in Rust
-
pinnable
A Mutex that can be pinned
-
key-mutex
Access mutexes by key
-
atomic_cell
Lock-free thread-safe mutable memory locations
-
countdown_latch
A synchronization aid that allows one or more threads to wait until a set of operations being performed in other threads completes
-
jotty
embeddable distributed processing framework for both short and long running batch jobs
-
kabuki
Name reservation
-
wasefire-sync
Portable non-blocking mutex
-
wakerset
no_std, no_alloc storage of Wakers embedded in the Future type
-
ach-cell
Atomic Channel
-
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.
-
sea-streamer-stdio
🌊 SeaStreamer Standard I/O Backend
-
flexible-locks
Flexible Locks
-
tasic
Tokio, Async_STD, Smol, Interface Crate
-
double-checked-cell
A thread-safe lazily initialized cell using double-checked locking
-
mtzip
making zip archives with multithreaded compression
-
hybrid-lock
A hybrid lock with optimistic locking
-
thinkofname/think_ecs
Source code of the game Univercity: https://store.steampowered.com/app/808160/UniverCity/
-
rhythm
Rate limiter which allows VIPs, written in Rust
-
task_queue
thread pool for Rust
-
yanoo
Lock-free mpmc broadcast channel
-
parking_lot_core
An advanced API for creating custom synchronization primitives
-
lockless
Composable, lock-free, allocation-light data structures
-
protoflow-core
Protoflow implements flow-based programming (FBP) for Rust using Protocol Buffers messages
-
maybe-async-channel
A channel which may or may not be async
-
lockness
TODO
-
exclusion-set
a lock-free concurrent set
-
workerpool-rs
workerpool for rust
-
logmap
A concurrent hashmap using a log for buckets
-
adirector
asynchronous tokio task spawner with a limited size
-
threadpool_scope
adding scopes to the threadpool crate
-
smol-axum
Integrations between
smol
andaxum
-
datacake-eventual-consistency
Eventually consistent state replication as a library (consensus, RPC and conflict resolution) for building your own eventually consistent databases
-
batch_queue
A single-producer single-consumer Rust queue with smart batching
-
rush_lua_engine
The rules engine is based on the rete algorithm
-
open-coroutine-hooks
The syscall hook for open-coroutine
-
tange-collection
Dataflow computation
-
navvy
MPSC Channel broker allowing channels of different types to be stored in a single data structure
-
mongo-lock
Distributed mutex locks with MongoDB
-
burstq
A multi-producer, multi-consumer channel that supports sending or receiving multiple values in a single operation
-
pairlock
A reader-writer lock with wait-free reads
-
mailbox_processor_rs
Actor abstraction inspired by the FSharp MailboxProcessor
-
thread-broadcaster
A SPMC (Single producer multi consumer) broadcasting channel to broadcast notifications between threads
-
multichannel
A mpmc priority multi channel with dynamic channel registration and freezing
-
scherben-map
Concurrent Sharded HashMap for Rust
-
waitmap
an awaitable concurrent hash map
-
agner
An actor toolkit inspired by Erlang/OTP
-
sync-extra
Convenience functions to Mutex and RwLock
-
af-cuda-interop
ArrayFire is a high performance software library for parallel computing with an easy-to-use API. This crate is an addition on top of ArrayFire crate to enable users to mix RAW OpenCL code in rust and ArrayFire.
-
voluntary-servitude
Thread-safe appendable list with lock-free iterator
-
kompact-component-derive
A derive macro for Kompact component definitions
-
rayon-macro
Macros enabling parallelism using the rayon crate
-
snowflake-multi-threaded
The rust-lang implementation of Twitter's id generator algorithm snowflake, it thread safety | Twitter 的id生成器算法snowflake的rust-lang 实现
-
delay-queue
A concurrent unbounded blocking queue where each element can only be removed when its delay expires
-
ccl
Fast datastructures for use in highly concurrent systems
-
eventbus
Safe, fast and concurrent event system, inspired by the MinecraftForge event bus
-
concurrent_open_map
A concurrent hashmap implementation in Rust
-
linux-futex
Futex: A Linux-specific fast user-space locking primitive
-
lf-queue
A lock-free multi-producer multi-consumer unbounded queue
-
locklessness
Composable, lock-free, allocation-light data structures
-
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
-
rework
Multi-threaded task processing in the Master-Worker pattern
-
static_locks
The
parking_lot
locks but usable in statics and const fn -
lft-rust
A lock-free threadpool implementation. We provide a traditional single queue threadpool and a lock-free threadpool
-
proc-lock-api
APIs for the proc-lock crate
-
cortex-m-rtfm
Real Time For the Masses (RTFM): a concurrency framework for building real time systems
-
melodium-repository
Repository managment crate for Mélodium, with dependency resolution and retrieval
-
bastion-utils
Bastion, the highly-available, fault-tolerant, async communication oriented executor
-
syncbox
Concurrency utilities for Rust
-
os-sync
synchronization primitives based on OS semaphore
-
unsync_channel
!Send/!Sync channels for Rust
-
metadata-store
store for recoverable metadata that is written in atomic batches
-
actress
actor library for Rust
-
boomerang_util
Boomerang
-
async-map
A rarely-locking, shared map for Rust