-
mio
Lightweight non-blocking I/O
-
tokio
An event-driven, non-blocking I/O platform for writing asynchronous I/O backed applications
-
tokio-rustls
Asynchronous TLS/SSL streams for Tokio using Rustls
-
mlua
High level bindings to Lua 5.4/5.3/5.2/5.1 (including LuaJIT) and Roblox Luau with async/await features and support of writing native Lua modules in Rust
-
deadpool
Dead simple async pool
-
futures-timer
Timeouts for futures
-
futures
streams featuring zero allocations, composability, and iterator-like interfaces
-
polling
Portable interface to epoll, kqueue, event ports, and IOCP
-
async-broadcast
Async broadcast channels
-
blocking
A thread pool for isolating blocking I/O in async programs
-
rdkafka
Rust wrapper for librdkafka
-
pollster
Synchronously block the thread until a future completes
-
bb8
Full-featured async (tokio-based) connection pool (like r2d2)
-
multer
An async parser for
multipart/form-data
content-type in Rust -
async-process
Async interface for working with processes
-
async-std
Async version of the Rust standard library
-
interprocess
communication toolkit
-
tokio-serial
A serial port implementation for tokio
-
futures-concurrency
Structured concurrency operations for async Rust
-
minus
An asynchronous data feedable terminal paging library for Rust
-
paho-mqtt
The Official Eclipse Paho MQTT Rust Client Library. This is a wrapper around the Paho C library
-
suppaftp
A super FTP/FTPS client library for Rust
-
async_zip
An asynchronous ZIP archive reading/writing crate
-
async-trait
Type erasure for async trait methods
-
want
Detect when another Future wants a result
-
amqprs
AMQP 0-9-1 client implementation for RabbitMQ
-
io-uring
The low-level
io_uring
userspace interface for Rust -
tower-sessions
🥠 Sessions as a
tower
andaxum
middleware -
ractor
A actor framework for Rust
-
keycloak
Admin REST API
-
event-listener
Notify async tasks or threads
-
cucumber
testing framework for Rust, with async support. Fully native, no external test runners or dependencies.
-
openraft
Advanced Raft consensus
-
futures-lite
Futures, streams, and async I/O combinators
-
async-io
Async I/O and timers
-
monoio
A thread per core runtime based on iouring
-
futures-locks
Futures-aware lock primitives
-
calloop
A callback-based event loop
-
apalis
extensible multithreaded background job processing for Rust
-
failsafe
A circuit breaker implementation
-
actix
Actor framework for Rust
-
tor-rtcompat
Compatibility layer for asynchronous runtimes, used by Tor
-
redis-async
An asynchronous futures based Redis client for Rust using Tokio
-
local-channel
A non-threadsafe multi-producer, single-consumer, futures-aware, FIFO queue
-
tokio-metrics
Runtime and task level metrics for Tokio applications
-
madsim
Deterministic Simulator for distributed systems
-
asynchronous-codec
encoding and decoding frames using
async/await
-
async-scoped
Spawn scoped (non 'static) asynchronous futures for async_std and tokio runtimes
-
tokio-graceful
util for graceful shutdown of tokio applications
-
unicycle
A scheduler for driving a large number of futures
-
futures-buffered
future concurrency primitives with emphasis on performance and low memory usage
-
eyeball
Add observability to your Rust types!
-
nb
Minimal non-blocking I/O layer
-
rsmq_async
Async RSMQ port to rust. RSMQ is a simple redis queue system that works in any redis v2.4+. It contains the same methods as the original one in https://github.com/smrchy/rsmq
-
stream-cancel
interrupting asynchronous streams
-
futures-signals
Zero cost FRP signals using the futures crate
-
tokio-native-tls
TLS/SSL streams for Tokio using native-tls giving an implementation of TLS for nonblocking I/O streams
-
containerd-shim
containerd shim extension
-
exponential-backoff
An exponential backoff generator with jitter
-
rxrust
Reactive Extensions
-
async-shutdown
one-stop solution for async graceful shutdown
-
kameo
Fault-tolerant Async Actors Built on Tokio
-
motore
modular and reusable components for building robust clients and servers. Motore is greatly inspired by Tower.
-
service-async
A Service like tower in async style
-
gix-actor
A way to identify git actors
-
kdbplus
Dual q/kdb+ interface for API to build a shared library and an IPC client
-
esrs
A Prima.it-opinionated library to achieve cqrs/es
-
actix-web-flash-messages
Flash messages for actix-web applications
-
c-ares-resolver
An asynchronous DNS resolver, backed by c-ares
-
rusty_falcon
Rust bindings for CrowdStrike Falcon API
-
mio-serial
A serial port implementation for mio
-
ws_stream_tungstenite
Provide AsyncRead/AsyncWrite over Tungstenite WebSockets
-
swiftide
Blazing fast, streaming pipeline library for AI applications
-
reactive-mutiny
async Event-Driven Reactive Library with advanced & optimized containers (channels) and Stream executors
-
tmq
ZeroMQ bindings for Tokio
-
swiftide-agents
Blazing fast, streaming pipeline library for AI applications
-
futures-bounded
bounding futures in size and time
-
pharos
Observer pattern which generates a futures 0.3 stream of events
-
tokio-retry
Extensible, asynchronous retry behaviours for futures/tokio
-
hirun
A concurrent framework for asynchronous programming based on event-driven, non-blocking I/O mechanism
-
wasm-bindgen-futures
Bridging the gap between Rust Futures and JavaScript Promises
-
genawaiter
Stackless generators on stable Rust
-
cxx-async
interoperability between C++ coroutines and asynchronous Rust
-
tls-api
TLS API without implementation
-
mml-lib
Emacs MIME message Meta Language (MML)
-
fn_graph
Dynamically managed function graph execution
-
async-speed-limit
Asynchronously speed-limiting multiple byte streams
-
fang
Background job processing library for Rust
-
crb
CRB | Composable Runtime Blocks
-
tokio-graceful-shutdown
perform a graceful shutdown on a Tokio based service
-
pexels-cli
client for the Pexels API
-
lamellar
asynchronous tasking runtime for HPC systems developed in RUST
-
poem-openapi
OpenAPI support for Poem
-
hydra
A framework for writing fault tolerant, highly scalable applications with the Rust programming language
-
async-native-tls
Native TLS using futures
-
fluvio-future
I/O futures for Fluvio project
-
futures-rustls
Asynchronous TLS/SSL streams for futures using Rustls
-
scoped-futures
imposing upper bounds on Future lifetimes
-
open-coroutine
efficient and generic stackfull-coroutine library
-
tokio-zookeeper
Asynchronous client library for interacting with Apache ZooKeeper
-
celery
Rust implementation of Celery
-
fvm_shared
Filecoin Virtual Machine shared types and functions
-
triggered
Triggers for one time events between tasks and threads
-
factorio-mlua
High level bindings to Lua 5.4/5.3/5.2/5.1 (including LuaJIT) and Roblox Luau with async/await features and support of writing native Lua modules in Rust. Fork with added Factorio Lua support
-
futures-rx
Rx implementations for the futures crate
-
runtimelib
Jupyter runtime library
-
trait-variant
working with impl traits in Rust
-
faktory
API bindings for the language-agnostic Faktory work server
-
tor-rtmock
Testing mock support for tor-rtcomapt
-
safina
Safe async runtime
-
async-ssh2-lite
Asynchronous ssh2
-
napi-calm-down
N-API bindings
-
dataloader
Facebook's DataLoader using async-await
-
async-global-executor
A global executor built on top of async-executor and async-io
-
async-recursion
Recursion for async functions
-
binary-stream
Binary stream reader and writer
-
partial-io
Helpers to test partial, interrupted and would-block I/O operations, with support for property-based testing through proptest and quickcheck
-
tokio_schedule
schedule tasks in tokio runtime
-
crosstown_bus
Event Bus with RabbitMQ for Rust
-
kafka
Rust client for Apache Kafka
-
poster
MQTTv5 client library written in Rust
-
async-fn-stream
Lightweight implementation of
async-stream
without macros -
stakker
A lightweight low-level single-threaded actor runtime
-
interruptible
Stops a future producer or stream from producing values when interrupted
-
async-walkdir
Asynchronous directory traversal for Rust
-
twilight-http-ratelimiting
Discord REST API ratelimiter implementations for the Twilight ecosystem
-
hypercore
Secure, distributed, append-only log
-
deno_unsync
A collection of adapters to make working with Tokio single-threaded runtimes easier
-
rs-event-emitter
simulate promise implementation for rust
-
apis
Reactive, session-oriented, asynchronous process-calculus framework
-
async-lsp
Asynchronous Language Server Protocol (LSP) framework based on tower
-
peace_resource_rt
Runtime resources for the peace automation framework
-
dynosaur
Dynamic dispatch for return position impl traits and async in Rust
-
syslog-rs
A native Rust implementation of the glibc/libc syslog
-
lazy-pool
Experimental lazy object pool
-
async-tempfile
Automatically deleted async I/O temporary files
-
rxr
Reactive extensions for event-driven applications
-
pinky-swear
Futures and async/await-ready Promises
-
compio
Completion based async runtime
-
aqueue
fast speed thread safe async execute queue
-
daktronics-allsport-5000
decoders for the Daktronics All Sport 5000's serial output
-
dark-std
asynchronous containers build on tokio. It uses a read-write separation design borrowed from Golang
-
tor-rpcbase
Low level functionality for Arti's RPC service
-
tiny-tokio-actor
tiny actor library on top of tokio
-
lcode
An application of terminal write leetcode.一个终端刷力扣的应用
-
round-based
Driver for MPC protocols
-
tiny_kafka
A tiny Kafka client library with producer and consumer functionalities
-
poll-promise
Poll the result of an async operation in a game or immediate mode GUI
-
conogram
An async wrapper for Telegram Bot API
-
popol
Minimal non-blocking I/O
-
krecik
Asynchronous, parallel external service checker (and reporter), using industry standard libraries: Curl, ngHTTP2 and OpenSSL
-
cancel-safe-futures
Alternative futures adapters that are more cancellation-aware
-
rust-parallel
Fast command line app in rust/tokio to run commands in parallel. Similar interface to GNU parallel or xargs.
-
filebuffer
Fast and simple file reading
-
pi-async-rt
Based on future (MVP), a universal asynchronous runtime and tool used to provide a foundation for the outside world
-
countio
Byte counting for std::io::{Read, Write, Seek} and its async variants from futures and tokio
-
ghost_actor
GhostActor makes it simple, ergonomic, and idiomatic to implement async / concurrent code using an Actor model
-
async-ringbuf
Async SPSC FIFO ring buffer
-
swiftide-query
Blazing fast, streaming pipeline library for AI applications
-
abscissa_tokio
Support for launching Tokio runtimes within Abscissa applications
-
async-graphql-actix-web
async-graphql for actix-web
-
ferrisgram
An elegent rust client for the Telegram Bot API
-
tigerbeetle-unofficial
Safe high level async bindings to tigerbeetle client library
-
mobc
A generic connection pool with async/await support
-
decrypt-cookies
A decrypt browser crate
-
rocketmq-filter
Unofficial Rust implementation of Apache RocketMQ
-
get_chunk
File iterator or stream with auto or manual chunk size selection
-
another-rxrust
A different implementation than
rxRust
for easier use ofReactiveX
inRust
-
tros
Your tros from tarantool TX thread to tokio(..and others!)
-
delay_timer
Time-manager of delayed tasks. Like crontab, but synchronous asynchronous tasks are possible, and dynamic add/cancel/remove is supported.
-
a10
io_uring library
-
debounced
building delayed
Future
s and debouncedStream
s that wait a given duration before yielding the most recent item -
async_smux
Asynchronous smux multiplexing library
-
wg
Golang like WaitGroup implementation for sync/async Rust
-
genawaiter2
Stackless generators on stable Rust
-
blockstore
An IPLD blockstore capable of holding arbitrary data indexed by CID
-
flourish
Convenient and full-featured signals for Rust
-
multishot
An async, lock-free, reusable channel for sending single values to asynchronous tasks
-
tokio-io-utility
Some helper functions for tokio::io
-
lemmy_db_views_actor
A link aggregator for the fediverse
-
actix-multipart-rfc7578
multipart/form-data (RFC7578) for Actix
-
yt-dlp
⚙️ A Rust library (with auto dependencies downloading) for yt-dlp 🎬️
-
irelia
wrapper around the native LoL APIs
-
pijul
A distributed version control system
-
fvm_actor_utils
Utils for authoring native actors for the Filecoin Virtual Machine
-
kube-coordinate
Kubernetes leader election using the coordination.k8s.io API
-
ya-gcp
APIs for using Google Cloud Platform services
-
kube-lease-manager
Ergonomic and reliable leader election using Kubernetes Lease API
-
futuresdr
An Experimental Async SDR Runtime for Heterogeneous Architectures
-
quick-protobuf-codec
Asynchronous de-/encoding of Protobuf structs using asynchronous-codec, unsigned-varint and quick-protobuf
-
async-object-pool
object pool implementation that uses asynchronous synchronization primitives only
-
async-dropper
The least-worst ad-hoc implementation of AsyncDrop as a Derive macro
-
stilgar
A lightweight, no-fuss, drop-in replacement for Rudderstack
-
async-change-tracker
reactive change notifications using futures
-
kompact
Kompics component model combined with the Actor model
-
hypercore-protocol
Replication protocol for Hypercore feeds
-
keen-retry
-- yet powerful -- zero-cost-abstractions & zero-copy lib for error handling & recovery
-
eureka-mmanager
An Actix actor collection for downloading manga, chapters, covers from Mangadex
-
postage
An async channel library
-
ate
Distributed immutable data store with strong encryption and authentication
-
tokio-retry2
Extensible, asynchronous retry behaviours for futures/tokio
-
certsd
automated, asynchronous LE certificate issuer
-
mio_wasi
Lightweight non-blocking IO
-
drop-stream
A stream that wraps another stream with a closure that is called once it is dropped
-
springtime-di
Dependency injection framework based on automatic component discovery and runtime autowiring
-
lazy_async_promise
Primitives for lazily getting data from futures with tokio for immediate mode guis
-
ipc-queue
FIFO queue described in fortanix-sgx-abi used for asynchronous usercalls
-
mail-message
A program for easy, quick, and fault tolerant sending of emails from the command line
-
containerd-client
GRPC bindings to containerd APIs
-
async-cuda
Async CUDA for Rust
-
b2_backblaze
basic async library to upload small files to backblaze b2 service
-
glommio
thread-per-core crate that makes writing highly parallel asynchronous applications in a thread-per-core architecture easier for rustaceans
-
async_cache
Async refresh cache
-
local-waker
A synchronization primitive for thread-local task wakeup
-
tokio-test
Testing utilities for Tokio- and futures-based code
-
pty-process
spawn commands attached to a pty
-
dptree
An asynchronous event dispatch mechanism for Rust
-
tokio-pipe
Asynchronous pipe(2) library using tokio
-
futures-util
Common utilities and extension traits for the futures-rs library
-
messagebus
allows intercommunicate with messages between modules
-
aj
Background Job based on Actix
-
tokio-scheduler-rs
JobScheduler written with tokio runtime, automatic retry, hook and custom storage supported
-
c-ares
wrapper for the c-ares library, for asynchronous DNS requests
-
rabbit-auto
Wrappers for lapin publishers and consumers
-
netidx-protocols
Protocols built on top of netidx
-
girlboss
async job manager with progress tracking
-
async_cell
A Cell<Option<T>> that you can await on
-
array__ops
A selection of useful array operations
-
ractor_actors
actors built with Ractor
-
mini_exercism
Minimalistic Rust library to interact with the Exercism.org APIs
-
rdkafka-sys
Native bindings to the librdkafka library
-
async-io-mini
Async I/O fork for embedded systems
-
distributed-scheduler
A distributed cronjob library
-
madsim-tokio
The
tokio
simulator on madsim -
nuclei
Proactive IO & runtime system
-
peekable
reader and async reader, which enhance your network programming experience
-
pgp-lib
High-level, asynchronous API for rPGP, a pure Rust implementation of OpenPGP
-
crb-agent
CRB | Composable Runtime Blocks | Agent
-
async-socks5
An async/.await SOCKS5 implementation
-
mikrotik-rs
Asynchronous Rust library for interfacing with MikroTik routers
-
llm_client
The Easiest Rust Interface for Local LLMs, and an Interface for Deterministic Signals from Probabilistic LLM Vibes
-
wgpu-async
Converts some WGPU callback methods to async methods
-
tokio-io-timeout
Tokio wrappers which apply timeouts to IO operations
-
notifier_hub
cannal subscribtion system
-
fundamentum-edge-daemon
The supported way to access Fundamentum's ecosystem from linux devices
-
libmqm-default
IBM® MQ Interface (MQI) and MQ Administration Interface (MQAI) structure defaults
-
qbittorrent_rust
An asynchronous library to interface with the qbittorrent WeBUI API
-
futures-scopes
Runtime agnostic, nestable, scopes for spawning non-static futures
-
keyring-lib
High-level, asynchronous API for keyring-rs, a cross-platform Rust library to manage credentials
-
actix-casbin
An Actix actor for casbin
-
s3tui
TUI application for multiple s3 account operations
-
mlua-codemp-patch
High level bindings to Lua 5.4/5.3/5.2/5.1 (including LuaJIT) and Roblox Luau with async/await features and support of writing native Lua modules in Rust
-
v_exchanges
Implementations of HTTP/HTTPS/WebSocket API methods for some crypto exchanges, using crypto-botters framework
-
kafru
Python Celery-inspired queuing library for Rust, using cron for scheduling and SurrealDB for storing queues, metrics, and schedules
-
tokio-stream
work with
Stream
andtokio
-
scoped-stream-sink
Easy way to make streams and sinks
-
dagrs
follows the concept of Flow-based Programming and is suitable for the execution of multiple tasks with graph-like dependencies. Dagrs has the characteristics of high performance and asynchronous execution…
-
etcdv3client
etcdv3 client
-
executor-trait
A collection of traits to define a common interface across executors
-
libuv-sys-lite
Tiny, raw bindings to libuv without linking to it
-
effectum
An embeddable task queue based on SQLite
-
aggligator
Aggregates multiple links (TCP or similar) into one connection having their combined bandwidth and provides resiliency against failure of individual links
-
stopper
an async stream and future stopper mechanism
-
unkey
An asynchronous Rust SDK for the Unkey API
-
monzo-lib
async Monzo client in pure rust
-
sn_sdkg
Safe Network Synchronous Distributed Key Generation: enables dealerless section key generation
-
ector
open source async, no-alloc actor framework for embedded devices
-
nosy
Change notification / observation / broadcast channels, with filtering and coalescing. no_std compatible.
-
tokio-process-tools
Interact with processes spawned by tokio
-
synchronized-writer
A tiny implement for synchronously writing data
-
async-event-emitter
Lightweight AsyncEventEmitter
-
apocalypse
actor framework for Rust
-
minior
Ergonomic Minio Client
-
nebkor-maelstrom
synchronous client for creating Maelstrom distributed clients
-
truba
The minimal tokio runtime based actors for Rust
-
hannibal
a small actor library
-
apalis-sql
SQL Storage for apalis. Use sqlite, postgres and mysql for background job processing
-
next-gen
Safe generators on stable Rust
-
monoio-codec
Codec for Monoio
-
peace_item_model
Data types for resource interactions for the Peace framework
-
okstd
The standard library that's ok
-
acton-reactive
Acton Reactive is the main crate of the Acton framework, designed for building reactive, event-driven, and asynchronous systems. It provides intuitive abstractions to make working with…
-
flatline
ssh-2.0 client library
-
ruloom
A thin wrapper around 'corosensei' that provides support for stackful coroutines in Rust (like Loom in Java or goroutines in golang)
-
tower-sessions-redis-store
Redis session store for
tower-sessions
-
fama
Pipeline Manager
-
coc-rs
wrapper around the Clash of Clans public API
-
embedded-runtime
A tiny async runtime for embedded devices
-
gasket
Staged Event-Driven Architecture (SEDA) framework
-
async_executors
Implements Spawn, SpawnLocal and SpawnHandle for commonly used executors
-
elfo
An asynchronous distributed actor framework with robust observability
-
cassette
single-future, non-blocking executor intended for building state machines
-
lighthouse-client
Client SDK for Project Lighthouse
-
decoyssh
A compact and portable SSH tarpit server
-
tokise
An asynchronous runtime compatible with WebAssembly and non-WebAssembly targets
-
turmoil
Simulation testing framework for distributed systems
-
async-shared-timeout
Async timeout that can be reset and shared
-
stream_throttle
Stream combinator, to limit the rate at which items are produced
-
freedom-api
Freedom API for Rustaceans
-
gem-rs
that serves as a wrapper around the Gemini API, providing support for streaming
-
async-time-mock-smol
Mockable time for use in async runtimes (smol compatibility)
-
stackfuture
wrapper around futures that stores the wrapped future in space provided by the caller
-
est
Extensions for the rust Standard library and Tokio
-
crossmist
Efficient and seamless cross-process communication, both synchronously and asynchronously
-
eventuals
Eventually consistent values
-
tower-batch-control
Tower middleware for batch request processing
-
hedwig
message bus for Rust
-
product-os-async-executor
Product OS : Async Executor provides a set of tools to handle async execution generically so that the desired async library (e.g. tokio, smol) to be used can be chosen at compile time.
-
danube-client
The async client for Danube Messaging Broker platform
-
rust-utils
Various utility routines used in the rust programs I have written
-
rio
GPL-3.0 nice bindings for io_uring. MIT/Apache-2.0 license is available for spacejam's github sponsors.
-
shadocal
A blazingly fast, Google calendar (more in future) event formatter webserver tool
-
futures-retry
Retry your Futures and Streams!
-
interthread
Auto implementation of the Actor Model
-
whirlwind
Collection of thread-safe, asynchronous data structures
-
miow
A zero overhead I/O library for Windows, focusing on IOCP and async I/O abstractions
-
my-awesome-rabbitmq-lib
working with RabbitMQ and asynchronous operations
-
infect
Intent/effect/task - A variation on the Model View Intent (MVI) and State Action Model (SAM) paradigms
-
winctx
A minimal window context for Rust on Windows
-
asteroid-mq
An embeddable message queue system
-
named-retry
retrying fallible asynchronous operations
-
delouse
will expose opinionated debugging stubs most useful for tokio based async programs
-
reactio
Low-Latency Event Driven Nonblocking Reactor Pattern
-
rseip
Ethernet/IP (CIP) client in pure Rust
-
co_managed
Create managed sub coroutines. Managed sub coroutines will be cancelled when the parent exit
-
uactor
The fastest and most modular actor system that doesn't force you to pay for what you don't need
-
ntex-grpc
GRPC Client/Server framework
-
gprs
A set of filtered and optimized Rust libraries creates a foundation for building modern web frameworks
-
translators
Free Google Translator without API key and limits
-
future-local-storage
An init-once-per-future cell for thread-local values
-
zephyrus
A slash-command framework meant to be used with twilight
-
pin-utils
pinning
-
kctf
A fast asynchronous library and cli to solve (or generate) proof-of-work challenges generated using the kctf scheme
-
vkapi2
vk api wrapper for rust
-
async-ffi
FFI-compatible
Future
s -
tokio-task-scheduler
A non-blocking task scheduler for Rust with fluent API, supporting interval-based and cron-like scheduling
-
splaycast
Stream-specific broadcast channel
-
tokio-shutdown
Wait for a stop signal across multiple threads
-
cache_loader_async
A thread safe loading cache with async loader functions based on tokio
-
tools_interface
Abstractions of serveral Wikipedia/Wikimedia/Wikidata-related tools
-
restate-sdk
Restate SDK for Rust
-
rusturn
TURN server and client
-
ics-watcher
A lightweight crate for monitoring ICS files or links and detecting changes, additions, and removals
-
esrc
Primitives for implementing event sourcing and CQRS systems
-
taskline
distributed task queue for Rust
-
railsgun
Excessive tooling for Result handling - If you want rails you got RAILS!
-
twilight-standby
filter wait for filtered incoming events for the Twilight ecosystem
-
tcpclient
Asynchronous tcpclient based on aqueue actor
-
simple-git
git interface for gix suitable for async context (with tokio)
-
tipsy
Cross-platform IPC for Tokio
-
pistones
An wrapper for the Piston code execution engine
-
mal-api
An asynchronous MyAnimeList (MAL) API library for Rust
-
xjbutil
A xjbly created utility library for my own use
-
agnostic
users who want to write async runtime-agnostic crate
-
rspack_futures
rspack futures
-
fil_actors_runtime
System actors for the Filecoin protocol
-
timeout-iterator
TimeoutIterator is a wrapper over any iterator that adds peek_timeout and next_timeout functions. The canonical use-case is parsing multi-line free-form records (such as tailing a log fime)…
-
process-lib
Cross-platform, asynchronous Rust library to run commands in pipelines
-
ads_client
An asynchronous, non-blocking ADS client
-
stressed
Universal CLI stress tester for competitive programming
-
bus_queue
Lock-free Bounded non-Blocking Pub-Sub Queue
-
z_osmf
z/OSMF Client
-
nominatim
Bindings to the reverse geocoding API powered by openstreetmap
-
mulligan
A flexible retry library for Rust async operations with configurable backoff strategies and jitter
-
pubnub
SDK for Rust
-
senders_receivers
Senders/Receivers implementation for Rust
-
async_zmq
Async version for ZeroMQ bindings
-
kuska-handshake
Secure Scuttlebutt handshake + boxstream library
-
tokio-io-rewind
rewind tokio::io::AsyncRead and tokio::io::AsyncWrite streams
-
async-oneshot-channel
async oneshot channel implementation
-
futures-signals-ext
Extension to futures-signals: MutableOption with combinators, spawning, predicate driven selections from SignalVec
-
mapped_futures
A collection of futures based on FuturesUnordered that supports insertion, removal and mutation of futures by key
-
batch-channel
async channel that reduces overhead by reading and writing many values at once
-
php-tokio
Use any async Rust library from PHP!
-
async-codec
creating async codecs
-
tower-fallback
A Tower service combinator that sends requests to a first service, then retries processing on a second fallback service if the first service errors
-
vmcircbuffer
Double Mapped Circular Buffer
-
rocketmq-client-rust
Unofficial Rust implementation of Apache RocketMQ
-
async_io_stream
IntoAsyncRead on steriods
-
eventastic_postgres
An example postgres event store for eventastic
-
futures-batch
An adaptor that chunks up elements and flushes them after a timeout or when the buffer is full. (Formerly known as tokio-batch.)
-
tokio-muxt
Timer for a limited set of events that multiplexes over a single tokio Sleep instance
-
rust-paper
Rust Wallpaper manager from ( https://wallhaven.cc/ ) for Linux/UNIX only
-
coasys_juniper
GraphQL server library
-
automerge_repo
automerge-repo
-
async-transmit
Trait for transmitting data to peers asynchronously
-
kafka-threadpool
An async rust threadpool for publishing messages to kafka using SSL (mTLS) or PLAINTEXT protocols
-
discro
DISCRete Observables for asynchronous Functional Reactive Programming (FRP)
-
eventbuzz
A safe, fast, concurrent event publish/subscribe system based on tokio(async), inspired by Spring events
-
torznab-toolkit
A safe, multi-threaded, async toolkit for adding Torznab APIs to programs
-
async-scgi
Async SCGI Client & Server
-
future-queue
Adapters to manage a queue of futures, where each future can have a different weight
-
sacs
Async Cron Scheduler for Tokio
-
retry-if
A tokio-compatible attribute-macro for decorating methods and functions with an exponential backoff
-
redis-work-queue
A work queue, on top of a redis database, with implementations in Python, Rust, Go, Node.js (TypeScript) and Dotnet (C#)
-
mm1
M/M/1! Queueing, do you speak it?!
-
rasi-mio
a rasi drivers implementation base on mio
-
madsim-rdkafka
The rdkafka simulator on madsim
-
aranya-policy-ifgen
Tools for generating Rust interfaces to Aranya Policies
-
pi_rt_file
async file 的封装,添加了多线程竞争排序。
-
resident-utils
Resident program library
-
elegant-departure
simplify graceful shutdown
-
tokio_kcp
A kcp implementation for tokio
-
linemux
providing asynchronous, multiplexed tailing for (namely log) files
-
rustygram
minimal and blazing fast telegram notification framework for Rust
-
containerd-shim-protos
TTRPC bindings for containerd shim interfaces
-
disintegrate
build event-sourced applications
-
napi_ext
Extends napi-rs with the ability to run local futures
-
godot_tokio
The tokio-async runtime wrapped in a gdextention object to be used as an engine singleton in your gdext project
-
commonware-log
Commit to a secret log and agree to its hash
-
bisync
write async-generic code
-
fundamentum-sdk-mqtt
MQTT client targeting Fundamentum IoT's MQTT broker
-
shutdown
can be used to gracefully exit (part of) a running program
-
meltdown
A lightweight service manager to help with graceful shutdown of asynchronous applications
-
read_until_slice
AsyncBufRead::read_until extension to take a slice as a delimiter instead of a single u8
-
constellation-rs
Constellation is a framework for Rust (nightly) that aides in the writing, debugging and deployment of distributed programs
-
tokio-rayon
Mix async code with CPU-heavy thread pools using Tokio + Rayon
-
tower-lsp-f
Language Server Protocol implementation based on Tower
-
actix-mqtt-client
A MQTT client based on the actix framework
-
ipc-rpc
A wrapper over servo/ipc-channel which provides many high level features
-
cbsk_socket_tokio
socket callback tool by tokio
-
rustix-uring
The low-level
io_uring
userspace interface for Rust -
pierport
Urbit pier import protocol implementation
-
hyperbee
Peer to Peer B-tree
-
async-tensorrt
Async TensorRT for Rust
-
persway
Sway IPC daemon
-
tower-memlim
Tower based middleware layer to limit requests based on the host's computer memory usage
-
singleflight-async
Singleflight in async style
-
async_async_io
AsyncRead
,AsyncWrite
traits but withasync fn
methods -
streamunordered
An efficient async stream multiplexer
-
scylla-rs
An async ScyllaDB driver built on an actor-model framework
-
bb8-valkey
A connection pool for Valkey
-
stream-wave-parser
The
stream-wave-parser
is a crate that treats a stream from WAVE file -
async-stomp
Unofficial successor to Asynchronous streaming STOMP client
-
makepad-futures-legacy
Makepad futures legacy
-
letslogic
providing interaction with the Let's Logic API
-
borrow_mutex
Async Rust Mutex which does not require wrapping the target structure
-
wired_handler
Wired's handler library
-
serial-thread
Asynchronous, multithreaded serial port communication library using mpsc::cjhannels or async-channels for efficient data handling
-
futures-map
Futures-based and hashmap-based alogrithms
-
kapacitor-udf
creating Kapacitor User Defined Functions (UDFs)
-
haalka_futures_signals_ext
vendored version of MoonZoon's futures_signals_ext, as it is yet to be released as a crate
-
async-rt
A small library designed to utilize async executors through an common API while extending features
-
ordered-stream
Streams that are ordered relative to external events
-
polkadot-omni-node
Generic binary that can run a parachain node with u32 block number and Aura consensus
-
deferred-future
模仿 jQuery.Deferred(),允许从 Future 实现类实例的外部对正在 pending 的 Future 对象进行 resolve 或 reject 处理。
-
tokio-send-fd
A wrapper for tokio::net::UnixStream to send file descriptors
-
proptest_async
proptest macro supporting async tests
-
procsem
Semaphore used to lock thread/task-spanning sequence of operations
-
timer-lib
A feature-rich Rust library for creating and managing timers
-
futures-test
Common utilities for testing components built off futures-rs
-
async-tls
Asynchronous TLS/SSL streams using Rustls
-
synch
A basic asynchronous timer implementation that uses the cortex-m SysTick peripheral
-
futures-io
The
AsyncRead
,AsyncWrite
,AsyncSeek
, andAsyncBufRead
traits for the futures-rs library -
lsp-async-stub
An LSP server stub for futures
-
async-rdma
async wrapper for RDMA ibvers lib
-
vss
A dead simple library to allow for easily reused shutdown signal handling
-
woddle
An async, synchronized, database-backed Rust job scheduler
-
yaaral
async runtime abstraction library
-
termusix
A terminal-based music player with a user-friendly terminal UI, built with Rust
-
short_future
Future with shorter lifetime for async closures
-
smol-potat
Proc macro for smol runtime
-
mosquitto-rs
An async MQTT client based on libmosquitto
-
async-select
select!
multiplex asynchronous futures simultaneously -
patharg
Treat "-" (hyphen/dash) arguments as stdin/stdout
-
tokio-hrtime
Hires timers for tokio
-
tower-sessions-rusqlite-store
(tokio-)rusqlite session store for
tower-sessions
-
tokio-js-set-interval
Allows you to use
setInterval(callback, ms)
andsetTimeout(callback, ms)
as in Javascript inside atokio
runtime. The library provides the macrosset_interval!(callback, ms)
andset_timeout!(callback, ms)
-
xscript
writing robust shell-script-like programs and running commands with ease
-
pasts
Minimal and simpler alternative to the futures crate
-
bsky-cli
CLI application for Bluesky using ATrium API
-
hakuban
Data-object sharing library
-
bipe
asynchronous I/O pipe
-
native_messaging
Async implementation of MDN native messaging. Provides the ability to install host manifest.
-
futures-boring
SSL streams for Futures built on top of the BoringSSL
-
fb_futures_ext
future crate extensions
-
ringlog
A fast and lightweight non-blocking logging framework
-
mio-pidfd
mio support for Linux's pidfd
-
some_executor
A trait for libraries that abstract over any executor
-
socksv5
SOCKS v4a and v5 basic building blocks to build your own async SOCKS application
-
tokio-stomp-rs
Asynchronous streaming STOMP client fork
-
ractor_cluster
Distributed cluster environment of Ractor actors
-
hass-rs
An async websocket client for Home Assistant
-
jni-utils
Extra Utilities for JNI in Rust
-
ocpp-client
OCPP Client Implementation. Use this library to implement an OCPP charge point
-
deno_os
OS specific APIs for Deno
-
asynk
Multithread asynchronous runtime and reactor
-
notify-future
Support asynchronous notification completion future
-
wait
Syntactic sugar for calling async functions outside of an async context
-
futures_ringbuf
Mock Type implementing AsyncRead/AsyncWrite for testing and examples
-
async_counter
Counter that implements a future to await on specific value
-
async-rate-limit
Common traits for rate limiting and implementations in async contexts
-
async-defer
Asynchronous Deferred Calls
-
state_machine_future
Easily create type-safe
Future
s from state machines — without the boilerplate -
ctf-pwn
Pwn utilities for Rust
-
cancellation-token
C#'s CancellationToken API
-
safina-sync
Safe structs for sharing or sending data between async tasks - ARCHIVED: Code moved to
safina
crate -
tokio-tower
Bridging the protocol gap between Tokio and Tower
-
act_rs
Act.rs is an actor library built to be used with the standard library and Tokio
-
eyeball-im
Observable collections based on the
im
crate -
wasmcloud-interface-factorial
Interface library for the wasmcloud factorial capability, wasmcloud:example:factorial
-
secret-lib
Cross-platform, asynchronous Rust library to retrieve secrets from different sources
-
swiftide-integrations
Blazing fast, streaming pipeline library for AI applications
-
amqp-client-rust
An asynchronous AMQP client library for Rust, designed for high-performance communication with RabbitMQ. Features include automatic queue and exchange management, message publishing, subscribing, and RPC support.
-
task_forge
A flexible and simple task pool for asynchronous execution
-
monoio-compat
A compat wrapper for monoio
-
inklings
A unified Rust API for various Large Language Model (LLM) providers
-
async-fs
Async filesystem primitives
-
openaction
creating plugins for the OpenAction API
-
actix-rt
Tokio-based single-threaded async runtime for the Actix ecosystem
-
cassandra-protocol
Cassandra protocol implementation
-
ultra-batch
Tokio-based library to batch and cache database queries or other data lookups
-
send-future
Ergonomic and performant fix for https://github.com/rust-lang/rust/issues/96865
-
crb-send
CRB | Composable Runtime Blocks | Send
-
messagepack-async
functional library for read/writing messagepack with tokio
-
tokio-socketcan
Asynchronous Linux SocketCAN sockets with tokio
-
gcp_access_token
pure rust implimentation to get google cloud access token for servers with service account credentials
-
mpi-sys
Message Passing Interface bindings for Rust
-
tokio_delayed_queue
Asynchronous delayed queue for Tokio runtime
-
monoio-rustls
Asynchronous TLS streams wrapper for Monoio based on Rustls
-
rust-multipart-rfc7578_2
multipart/form-data (RFC7578)
-
duplicate-checker
A duplicate file checker
-
par-stream
Asynchronous parallel streams analogous to rayon
-
screeps-async
Tick-aware Async runtime for Screeps
-
spin_on
inefficient Future executor
-
tokio-nats
Async-await ready NATS library
-
async-rate-limiter
Implements a token bucket algorithm that can be used to limit API access frequency. Written in pure Rust.
-
libublk
building linux block device in userspace
-
livekit-runtime
Async runtime compatibility layer for LiveKit
-
webex
Interface to Webex Teams REST and WebSocket APIs
-
asynclog
asynchronous log library
-
peace_webi_model
Web interface data types for the peace automation framework
-
moro-local
Experimental structured concurrency support for async Rust (similar to trio's nurseries). Works with non-Send futures on stable Rust.
-
rmp-futures
Async Rust MessagePack and MessagePack-RPC
-
minos
Authorization library
-
asynk-strim
Lightweight stream generator library
-
tokactor
A actor model framework wrapped around tokio
-
handle
Trait for asynchronous context pipeline
-
aws-parameters-and-secrets-lambda
Cache AWS Secrets Manager secrets in your AWS Lambda function
-
zookeeper-async
An async ZooKeeper client
-
upstox-rust-sdk
SDK to access Upstox's Uplink v2 APIs programmatically
-
typed-emitter
Typed Async event emitter
-
aa-sms
Send messages from with Andrews & Arnold’s SMS API
-
tbot
Make cool Telegram bots with Rust easily
-
tokio_gen_server
Elixir/Erlang-GenServer-like actor on the Tokio runtime
-
acton-core
Acton Core provides the core functionality and abstractions used by the Acton Reactive crate. It includes the essential building blocks for creating reactive and distributed systems.
-
pi_async
Based on future (MVP), a universal asynchronous runtime and tool used to provide a foundation for the outside world
-
async_sync
handling asynchronous and synchronous operations seamlessly
-
slim-futures
Asynchronous tools that intends for smaller binary size
-
readwrite
Combine Read and Write into a single Read+Write object
-
dwn
Decentralized Web Node
-
knien
Typed RabbitMQ interfacing for async Rust
-
ksoft
KSoft.SI api wrapper written in pure Rust
-
stream-reconnect
Stream-wrapping traits/structs that automatically recover from potential disconnections/interruptions
-
event_iterator
Asynchronous lending iterator
-
background-jobs-sled
Sled storage backend for background-jobs
-
sparkle-convenience
A wrapper over Twilight designed to make it more convenient to use
-
tokio-i3ipc
Bindings for i3 and tokio allowing async applications to communicate with i3 over it's IPC interface. Contains futures implementations and convenience functions for working with i3.
-
git-next-server-actor
Server actor for git-next, the trunk-based development manager
-
collections-futures
working with futures through collections types
-
ticque
Take a queue for a resource
-
ng-repo
Repository library of NextGraph, a decentralized, secure and local-first web 3.0 ecosystem based on Semantic Web and CRDTs
-
signal-hook-tokio
Tokio support for signal-hook
-
mm1-node
M/M/1! Queueing, do you speak it?!
-
extend_mut
extending exclusive references
-
async-executor
Async executor
-
async-time-mock-async-std
Mockable time for use in async runtimes (async-std compatibility)
-
ply_jobs
ability to run background jobs on a schedule
-
alicemq
Wapper for the amqprs rabbitMQ library
-
tonic-side-effect
Tower service that can monitor if a Tonic request frame was produced prior to error
-
lua_actor
Lua Actor for Rust(sync/async)
-
tokio-lxi
LXI protocol abstractions for Tokio
-
piscina
generic pool that supports both sync and async
-
passivized_vault_client
Vault Client - initialize and monitor Hashicorp Vault nodes
-
pegy
A derive based parser generator
-
legend-saga
working with RabbitMQ and asynchronous operations
-
google-cloud-ai
A gRPC-based crate designed to interact with Google Cloud AI API
-
futures-timeout
that provides timeouts for futures and streams
-
parquet-format-async-temp
Temporary crate containing thrift library + parquet definitions compiled to support read+write async
-
tor-log-ratelim
Facility for rate-limiting log messages in Arti
-
isoprenoid
signals runtime framework backing flourish
-
async_shared
signal implementation
-
maelstrom-util
by non-WASM Maelstrom libraries and binaries
-
openraft-memstore
A in-memory implementation of the
openraft::RaftStorage
trait -
replay-channel
A broadcast channel where new receivers replay all past messages before receiving new ones
-
multi-readers
Combining multiple readers
-
sodium
FRP (Functional Reactive Programming)
-
zeroconf-tokio
Tokio-based wrapper around the zeroconf crate, which provides mDNS service discovery and registration capabilities
-
cyberex
Utilities Library
-
tactix
Actor Model based on Tokio
-
libevent-sys
Rust FFI bindings to the libevent library
-
orsomafo
Event dispatcher crate
-
spawns
Async runtime agnostic thread context task spawner for Rust
-
async-observable
Async & reactive synchronization model to keep multiple async tasks / threads partially synchronized
-
async-utf8-decoder
Convert AsyncRead to incremental UTF8 string stream
-
prometheus-utils
built on top of the prometheus crate
-
busstop
A command and query bus
-
lookit
Asynchronously connect to devices
-
async-unsync
asynchronous, unsynchronized (thread-local) channels and semaphores
-
rspl
A stream processor language
-
noosphere-collections
Collection data types that are needed by an efficient implementation of Noosphere's IPLD data structures
-
xtra
A tiny actor framework
-
monoio-thrift
Thrift for Monoio
-
tokio-util
Additional utilities for working with Tokio
-
rendezvous
Easier rendezvous channels for thread synchronization
-
stund
An SSH tunnel maintenance daemon
-
tokio-serde-cbor
Integration of serde_cbor into tokio-io, to allow sending CBOR encoded frames across network (and possibly through other transports)
-
suika_utils
A small utility library for the suika web stack
-
actix-daemon-utils
Daemon Utilities by actix
-
async-task
Task abstraction for building executors
-
reactor-trait
A collection of traits to define a common interface across reactors
-
rocketmq-runtime
Unofficial Rust implementation of Apache RocketMQ
-
felicia
service for accessing and sharing lists of bad actors
-
async_zip_futures
An asynchronous ZIP archive reading/writing crate using futures-rs
-
async-graphql-tide
async-graphql for tide
-
crossword_generator
generating crossword from provided words
-
pcap-async
Async/Stream Extensions for libpcap
-
axum-limit
A rate limiting library using token buckets, centered around extractor-based limits for async web applications
-
bb8_surrealdb2
Surrealdb support for the async bb8 connection pool
-
futures-core
The core traits and types in for the
futures
library -
mlua-luau-scheduler
Luau-based async scheduler, using mlua and async-executor
-
baildon
B+Tree library
-
pupactor
actor model library built with tokio
-
thread-waker
Waker implementation using current thread token
-
scipio
A set of utilities to allow one to write thread per core applications
-
aiven_rs
sdk to interact with aiven-cloud apis
-
dialectic
Transport-polymorphic, asynchronous session types for Rust
-
sn_consensus
Safe Network Membership: Enables nodes to dynamically join and leave a section
-
async-wormhole
Async calls across non-async functions
-
miau
Async aware and extensible layered configuration system
-
moxie
Incremental runtime for interactive software
-
async_logger
Asyncronous logger allows writing arbitrary slices to a memory buffer, which then processed by a writer in it's own thread
-
futures-yamux
The yamux protocol implementation, rewritten from the ground up
-
lichess-api
client for Lichess API v2.0.0
-
async-injector
Reactive dependency injection for Rust
-
graceful-shutdown
Graceful Shutdown for async code
-
nolocal-block-on
futures_lite::future::block_on that can run without using thread-locals
-
diazene
Actor for Rust (with Tokio)
-
tempo-rs
& minimal client to connect and interact with RTE's 'Tempo Like Supply Contract' API
-
sonor
controlling sonos speakers
-
yamaha-rcp
Remote control of Yamaha mixing consoles using TCP/IP networking
-
luis_sys
FFI bindings for Microsoft LUIS API
-
fil_builtin_actors_builder
WASM builder for builtin Filecoin actors
-
oneshot-handshake
providing a symmetric one time use channel type
-
lending-stream
A lending version of Stream
-
ticks
ergonomic Rust wrapper for the TickTick Open API
-
flurx
Create reactive asynchronous data flow
-
agixt-sdk
Rust SDK for AGiXT - A powerful AI agent framework
-
any-mpsc
An mpsc that allows arbitrary types to be passed through
-
async-blocking-stdio
std::io::std{in(), out(), err()} but async
-
goods
Async assets system
-
agnostik
Executor Agnostic Runtime that can run your futures with your favourite Executor
-
pollable-map
Utilites for storing futures and streams in as a pollable map
-
clia-rcproxy
A lightweight, fast and powerful Redis Cluster Proxy written in Rust
-
futures-delay-queue
Async delay queue backed by async-std and futures-timer
-
akinator-rs
wrapper around the undocumented Akinator API
-
acu
building asynchronous actors
-
awak
A small async runtime for Rust
-
foreback
Future adapters for running aditional work in the background
-
textmode
terminal interaction library backed by a real terminal parser
-
kumoko
asynchronous server/client crate built on tokio for easy two-way streaming
-
async_tasks_recorder
A struct for recording execution status of async tasks with async methods
-
hypixel_api
Generic wrapper around the hypixel api (automatic rate-limiting on client-side)
-
stdout-channel
Write stdout to an async queue
-
tub
Async Pool
-
baton
channel for receiving updates per field
-
thin_main_loop
Thin, cross-platform, main event loop. A building block for native GUI applications, among other use cases.
-
tokio_wasi
An event-driven, non-blocking I/O platform for writing asynchronous I/O backed applications
-
selectme
A fast and fair select! macro for asynchronous Rust
-
wrtc
Wrapper around webrtc-rs library, focused on developer experience
-
pwner
Process Owner crate that allows ergonomic access to child processes
-
miniloop
The simpliest async executor without heap memory allocation
-
ruchei
working with many streams
-
swimos_future
SwimOS Future Utilities
-
cb_fut
Call function that return value via callback without a callback
-
aoc_leaderboard
Strongly-typed wrapper for Advent of Code leaderboard data
-
sc2
StarCraft II Client API
-
async-fuse
Helpers for fusing asynchronous computations
-
rx_rust_mp
A protoype implementation of the ReactiveX API in Rust using a message passing approach
-
fure
Retrying futures using different policies
-
tokio-file
Asynchronous file I/O for Tokio
-
wiremock_logical_matchers
Logical matchers for use with wiremock
-
compio-driver
Low-level driver for compio
-
proxy-scraper
command-line tool for scraping proxy information
-
adventure
your great adventure for the various type of requests
-
night
A scalable Task Queue for executing asynchronous tasks in topological order
-
stakker_mio
Mio I/O polling integration for the Stakker crate
-
didcomm-rs
DIDComm messaging v2 specifications implementation: https://identity.foundation/didcomm-messaging/spec/
-
async-task-tracker
A task tracker used for waiting until tasks exit
-
tokio-zmq
Futures abstractions for ZeroMQ on the Tokio event-loop
-
pingora-timeout
Highly efficient async timer and timeout system for Tokio runtimes
-
maily
easy, quick, and fault tolerant sending of emails
-
cbsk_run
async pool tool
-
rustygear
Client library for communicating via the gearman protocol
-
mamenoki
Complete implementation of a Beanstalkd client based on the Tokio runtime
-
ksqldb
A thin wrapper around the KSQL DB REST API to make it more ergonomic to work with
-
discern
implementing the Command Query Responsibility Segregation (CQRS) pattern
-
cbsk_socket_rayon
socket callback tool by rayon
-
pptr
Type-Driven Asynchronous Actor Runtime
-
async-rustbus
An asynchronous implementation of the DBus protocol based on rustbus
-
tailf
A async
tail -f
for files -
waterark
Watermark for implementing optimistic SSI (Serializable Snapshot Isolation) transactions
-
synerlogikos
A high-level, generic, abstracted Rust library for building any integration. It is designed to abstract away common patterns found in all integrations multiple times.
-
peace-performance
osu! pp & stars calculation. Peace edition
-
iroh-io
async local io
-
hollywood
actor framework
-
telegram-bot-ars
creating Telegram bots
-
async-sleep
Async Sleep
-
tk-listen
A set of helper futures allowing to listen TCP (or unix) socket with resource limits and proper error handling
-
conva_ai
Rust SDK for using CONVA AI Copilots
-
peace_flow_model
Flow data model for the peace automation framework
-
webhttp
-
supply-chain-trust-example-crate-000054
Lightweight non-blocking I/O
-
logic-mesh
Control logic engine using event based and reactive blocks written in Rust
-
zeebest
An unofficial zeebe client for the future!
-
curseforge
A straightforward asynchronous wrapper around the CurseForge Core API. Public API is subject to change before 1.0.0.
-
stop-token
Experimental cooperative cancellation for async Rust
-
nsq-client
Rust client for the NSQ realtime message processing system
-
capp
Common things i use to build Rust CLI tools for web crawlers
-
ref_count
Efficient, low-level asynchronous synchronization for real-time and embedded systems
-
winmsg-executor
Per-thread async rust executor for windows
-
pausable_future
Pausable and resumable future, useful in background tasks
-
dioxus-v04-optional-hooks
Optional futures for Dioxus 0.4.0-0.4.3
-
pgboss
job queueing service
-
io_uring_buf_ring
Help user create and manage io-uring buffer-ring
-
tokio_based
BASED Async Single-threaded Execution Dispatcher
-
queen
message queue
-
apalis-cron
extensible library for cron-like job scheduling for rust
-
deluge
A highly concurrent stream library driving the underlying futures either concurrently or in parallel to process streaming operations as quickly as possible
-
polly-scheduler
A robust task scheduling system leveraging Tokio, with built-in fault tolerance, persistence, and recovery capabilities to ensure seamless task management and execution
-
mini-c-ares-resolver
An asynchronous DNS resolver, backed by mini-c-ares
-
libmqm-sys
IBM® MQ Interface (MQI) and MQ Administration Interface (MQAI) bindings
-
arangoq
An AQL query builder layer and ArangoDb client for rust
-
hydra-websockets
A websocket server for the hydra framework
-
negahban
🧐 A simple file watcher, based on
notify
, designed to be fast, easy-to-use and async friendly -
msq
legacy Master Server Query Protocol
-
tourniquet
Async native round-robin manager for remote services
-
extreme
Extremely boring async function runner. MIT/Apache-2.0 license is available for spacejam's github sponsors.
-
pi_async_buffer
Asynchronous Buffer for IO
-
swiftide-indexing
Blazing fast, streaming pipeline library for AI applications
-
event-source
Zero cost async immediate event dispatching
-
rabbit_mqr
Extremely Simplified RabbitMQ Client
-
tokio-shared
Share tokio Runtime bwtween dylibs
-
flo-state
Lightweight actor library
-
cannyls_rpc
RPC library for operating cannyls's devices from remote nodes
-
io-pipe
A fast and thread-safe library for creating multi-writer and single-reader pipelines in Rust
-
abstract-ns
Abstract name service traits for use with futures (and tokio)
-
compio-net
Networking IO for compio
-
task-motel
Opinionated (Tokio) task manager with nested task groups and stoppable tasks
-
async_msp_cli
Async msp cli for iNav and BetaFlight
-
zookeeper-cache
ZooKeeper client cache
-
smoltimeout
A way to poll a future until it or a timer completes
-
libaio-futures
Straightforward Linux AIO using Futures/async/await
-
terminusdm
Terminus Download Manager. Download files, resume interrupted downloads, and keep a history of your downloads - within terminal UI.
-
rocketmq-client-v4
rocket mq rust client for remote protocol. works on rocket mq V4
-
kafka-rs
Native Rust Kafka client, built upon kafka-protocol-rs and Tokio
-
lutetium
tokio based simple actor library
-
makepad-futures
Makepad futures
-
test_executors
async executors for testing
-
async-notify
A general version async Notify, like
tokio
Notify but can work with any async runtime -
metatrait
RPITIT Monads
-
taskalicious
Common Rust task workers
-
vesper
A slash-command framework meant to be used with twilight
-
async-gen
Async generator in stable rust using async/await
-
async-waitgroup
Golang like WaitGroup implementation that supports both sync and async Rust
-
reusable-box-future
A reusable
Pin<Box<dyn Future<Output = T> + Send>>
-
l337
connection pooler
-
roux-stream
A streaming API for the roux Reddit client
-
retrier
A wasm-compatible retry library for futures
-
madsim-real-tokio
An event-driven, non-blocking I/O platform for writing asynchronous I/O backed applications
-
plumbing
An async abstraction to pipeline requests through a channel
-
merge-streams
Merge multiple streams into one
-
packet-ipc
Share packets between services using servo ipc
-
awaitable
type with input and output that can be stored in container
-
kioto-uring-executor
multi-threaded wrapper around tokio-uring
-
cntrlr
async embedded framework
-
metalmq
server
-
xilinx-dma
Userspace Xilinx AXI DMA Interface
-
pirates
async RPC lib
-
rabbit_borough
Create a RabbitMQ consumer project with minimal effort, by bypassing templating, configuration and complicated resiliency logic
-
embedded-io-convert
Convert embedded-io-async types back to futures ones (nightly only)
-
stream_router
A Future aware router to dynamically route between Streams and Sinks
-
ruchei-route
Sinks with routes
-
thread-executor
Lightweight futures executor using std::thread::park
-
agner-actors
An actor toolkit inspired by Erlang/OTP (actors)
-
tiny_future
Condvar
based future with automatic cancellation on drop -
async-lazy
A value which is initialized on the first access, with an async function
-
msft-runtime
Windows async helpers
-
futures-ratelimit
Bounded flavors of futures' FuturesUnordered and FuturesOrdered
-
smol
A small and fast async runtime
-
moeval
a toy interpreter
-
fork_stream
Clone any stream
S
where<S as Stream>::Item: Clone
-
viaduct
A duplex communication channel between a parent and child process, using unnamed pipes
-
rexecutor-sqlx
A robust job processing library
-
kioto-serial
Provide serial port I/O using tokio
-
async-gcode
An async gcode parser for no_std targets
-
rip-starttls
Sans I/O implementation of https://duesee.dev/p/avoid-implementing-starttls/
-
act-locally
single-threaded async actors with ordinary functions as handlers and plainly typed messages
-
tierkreis-runtime
Runtime implementation for the tierkreis quantum-classical hybrid workflow orchestration tool
-
futuristic
Extensions to the futures crate
-
murray
A minimal actor definition macro using Tokio
-
handoff
An unbuffered, asynchronous, single-producer/single-consumer channel
-
napi_async_local
Extends napi-rs with the ability to run local futures
-
passivized_docker_engine_client
Docker Engine Client - manage and run containers, images, and volumes
-
callbag
spec for reactive/iterable programming
-
situwaition
Run a closure continuously, until is succeeds or times out
-
read-progress-stream
Stream reader wrapper that tracks the number of bytes read
-
async-sse
Async Server Sent Event parser and encoder
-
radix-router
Rust port of httprouter
-
napmap
Async HashMap that halts requester tasks until the requested data is accessible
-
lifeline
dependency injection library for asynchronous message-based applications
-
crb-actor
CRB | Composable Runtime Blocks | Actor
-
prost-codec
Asynchronous de-/encoding of Protobuf structs using asynchronous-codec, unsigned-varint and prost
-
async-minecraft-ping
An async Rust client for the Minecraft ServerListPing protocol
-
parity-runtime
Tokio runtime wrapper
-
mqtt_actor
An mqtt adapters (from port and adapters) to be used with actix actors
-
futures_cbor_codec
A codec for framing an AsyncRead/AsyncWrite with cbor for all types that are serializable with serde
-
prevayler-rs
System prevalence in rust
-
carboxyl
functional reactive programming
-
pw-telegram-bot-fork
creating Telegram bots
-
lazy_async_pool
An asyncronous object pool that generates objects on the fly
-
async-xml
deserializing XML data asynchronously
-
islabtech-upw-sensor-v1
Rust client library for remote control of the ISLabTech UPW Sensor v1
-
cortex-sources
Ready-made source implementations for various data inputs in the Cortex ecosystem
-
async_singleflight
Async singleflight
-
tokio-bitstream-io
Tokio port of bitstream-io: Library for reading/writing un-aligned values from/to streams in big-endian and little-endian formats
-
rust-concurrent
Fast command line app in rust/tokio to run commands in parallel. Similar interface to GNU parallel or xargs.
-
maelstrom-node
Maelstrom Rust node framework
-
mediator
pattern in Rust
-
async-recorder
Store records without waiting for your persistence backend
-
async-nats-tokio-rustls-deps
Fork of Asynchronous TLS/SSL streams for Tokio using Rustls
-
starbase_events
Async and mutable event system
-
rants
An async NATS client library
-
swarm-commander
Manage tons of commands asynchronously
-
untokio
Automatically create tokio runtimes
-
tokio-async-drop
macro to enable async drop in a tokio multithreaded runtime
-
gcal_rs
A blazingly fast, hand written Google calendar API in Rust
-
tobytcp
A little library for sending messages over a tcp stream
-
openai-api
OpenAI API library for rust
-
tokio-uring
io-uring support for the Tokio asynchronous runtime
-
swimos_byte_channel
SwimOS Byte Channel
-
riker
Easily build fast, highly concurrent and resilient applications. An Actor Framework for Rust.
-
in-keys
utilizing streams in a convenient
Terminal
construct -
tokio-graceful-shutdown-without-anyhow
perform a graceful shutdown on a Tokio based service
-
tokio-socks
Asynchronous SOCKS proxy support for Rust
-
slings
A small async runtime based on io-uring for Rust
-
hooch
A small async runtime that's been bootlegged for my projects
-
rumqttlog
kafka inspired rumqtt's mqtt commitlog
-
rust-rsm
RSM:A Realtime Software Middleware framework. Asynchronous, event driven framework
-
genawaiter2-macro
Convenience macros for generators (genawaiter2)
-
blocker
Block rust futures to create a synchronous wrapper around an asynchronous api
-
linked-futures
Link futures into a block, which stops all of the included futures when any of the futures complete
-
task-collection
Types for managing and waiting on groups of tasks
-
pochta
Addressable channel registry
-
backie
Background task processing for Rust applications with Tokio, Diesel, and PostgreSQL
-
pantry
Temporary storage for reusing values that may decay
-
saas-zmq
ZeroMQ tools by using Publish-Federation
-
swimos_trigger
SwimOS Asynchronous Trigger
-
tokio-lk
Futures-aware lock-by-id primitives
-
async-ctrlc
Async wrapper of
ctrlc
-
actix-signal
Manage the lifecycle of an actix actor with its address
-
async-usercalls
An interface for asynchronous usercalls in SGX enclaves. This is an SGX-only crate, you should compile it with the
x86_64-fortanix-unknown-sgx
target -
streamcatcher
A thread-safe, shared (asynchronous), almost-lockless stream buffer
-
streamline
Reversible futures::Stream-based state machines
-
csv-async
CSV parsing for async
-
alan-runtime
A runtime in Rust to run AGC or Alan Graphcode, alan's bytecode format
-
deadqueue
Dead simple async queue
-
event-listener-strategy
Block or poll on event_listener easily
-
auto-future
For quickly making a struct into a future via an async fn
-
wasmflow-packet
encapsulating the message packets sent across Wasmflow components
-
stow
Cloud storage abstraction package for Rust
-
zellij-utils
Zellij client and server
-
split-stream-by
Stream extension crate for splitting a Stream into two per a predicate
-
tracing-orchestra
Give me more instruments!
-
shutdown-handler
A shutdown handler that allows all parts of an application to trigger a shutdown
-
visiting_ref
Container types that asynchronously return ownership of a value to another context upon exiting scope
-
hls_lfcd_lds_driver
Rust driver for ROBOTIS HLDS HLS-LFCD-LDS (LDS-01)
-
heph
actor framework based on asynchronous functions
-
rt-local
Thread local asynchronous runtime working with platform-specific event loops
-
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.
-
tokio-tar
async TAR file reader and writer. This library does not currently handle compression, but it is abstract over all I/O readers and writers. Additionally, great lengths are taken to ensure that the entire…
-
snarc
Sendable Non-Atomically Reference Counted
-
dabus
Dynamic Aplication Controll Bus - an asynchronous, event based module system for thoes who want to move fast and *not* break things
-
futures-executor
Executors for asynchronous tasks based on the futures-rs library
-
test-with-tokio
attribute macro for tests using tokio with cases and async guards
-
bongonet-boringssl
BoringSSL async APIs for Bongonet
-
naumi
Lightweight and fast data transfer protocol. Fast de/serialization and tiny size!
-
safina-threadpool
Safe thread pool - ARCHIVED: Code moved to
safina
crate -
async-gate
A Tokio-powered asynchronous gate (analogous to a flag and highly inspired by Python’s
asyncio.Event
, but can be waited for to become ‘false’ too) -
async-mavlink
An async adapter for mavlink conections
-
susync
An util crate to complete futures through a handle. Its main purpose is to bridge async Rust and callback-based APIs.
-
verge
An experimental actor library
-
aral
Async Runtime Aggregation Layer
-
async-copy-progress
Asynchronous copying with progress callbacks
-
stream-broadcast
Runtime independent broadcast, which only polls it's underlying stream if no pending data is available
-
app_ctx
An AppCtx implementation in Rust, like ApplicationContext in SpringBoot
-
heph-inbox
Bounded capacity channel designed to be used as inbox for actors. Also supports one shot channels.
-
terminal-wait-exit
wait user exit terminal, like Ctrl+C
-
rumpsteak
Session types for asynchronous communication between multiple parties
-
fb_futures_01_ext
Extensions for future 0.1 crate
-
async-mq
Zero-cost async-await abstraction of lapin AMQP client crate
-
timeware
timer used to schedule execution of closures at a given timestamp
-
tokio-libtls
Tokio bindings for LibreSSL's libtls
-
async-actor
actor framework for Rust
-
streammap-ext
StreamMap of Tokio with altered
next
that returns when stream is dropped -
activitystreams-types
Base types from the Activity Streams spec
-
tauri-specta
Completely typesafe Tauri commands
-
this-state
way to store state in a thread-safe manner as well as a way to asynchronously wait for state changes
-
circulate
Lightweight PubSub framework that supports both sync and async
-
selecting
Cross-platform wrapper over select
-
bp3d-threads
threading library intended to simplify concurrency in BP3D
-
smolscale
A high-performance async-task scheduler
-
mio-wakeq
mio support for custom event queue via Waker
-
actix-interop
Use async/await syntax with actix actors
-
woven
set of async combinators, usable in a no_std environment
-
rio_rt
A minimal async runtime with an experimental ambition to be an portable and interoperable async runtime for Rust
-
multiqueue2
A fast mpmc broadcast queue
-
coachman
rust asynchronous task manager built on top of tokio framework
-
speedracer
racing futures and ranking the results
-
futures-websocket
A futures-based websocket implementation
-
side-futures
Send future for execution on the runtime that may be in a different thread
-
rocketmq-rust
Unofficial Rust implementation of Apache RocketMQ
-
sigio
signal-based async io
-
stream-guard
RAII wrapper around Stream that invokes a custom action on drop
-
mpc-bench
Multi-party computation experimentation library
-
futures_codec
encoding and decoding frames using
async/await
-
act-zero
Ergonomic actor system
-
dialectic-compiler
Session type macro compiler for the Dialectic crate
-
bean_factory
bean factory,support inject reference bean
-
must_future
A wrapper future marked must_use - mainly to wrap BoxFutures
-
csnmp
Community-based async (Tokio) SNMP client library
-
proxycurl-linkedin-rs
client for the Proxycurl LinkedIn API
-
gentian
proc macro that transforms generators to state machines
-
cs-utils
Common utilities
-
tokio-stdin-stdout
Thread- and future::sync::mpsc-based AsyncRead/AsyncWrite stdin/stdout with little buffering
-
piston_rs
An async wrapper for the Piston code execution engine
-
tracing-actix
Allow tracing actor futures in actix
-
async-compatibility-layer
an abstraction layer for using both async-std and tokio
-
dstream
DelayedStream - delays items and drops same items coming within given interval
-
rlua-async
Async support for rlua, via coroutines
-
tokio-switching-sleep
A tokio Sleep with a switchable state
-
js-sys-futures
working with the futures and js-sys crates
-
waitgroup
Async waitgroup for a collection of task to finish
-
async-stream-lite
Proc macro-free async/await Rust streams
-
dyn-future
Convenient and fast dynamic Futures for Rust
-
async-send-fd
A wrapper for async UnixStream's to send file descriptors
-
async-hid
A async library for interacting with HID devices
-
heim-cpu
Cross-platform CPU information
-
puff-rs
Puff - Deep Stack Python Runtime and GraphQL library
-
callback-result
Assists in converting the callback function's method of obtaining results into the await method
-
spekt
std::future::Future and Result-based testing trait for managing the lifecycle of stateful, asynchronous tests
-
flo_stream
Pubsub and related streams for Rust futures
-
tokio-rusqlite
Asynchronous handle for rusqlite library
-
nyantrack-common
Common data types and functionality for NyanTrack
-
background-jobs-tokio
in-process jobs processor based on Tokio
-
key-lock
mutual exclusion by keys
-
simple-scheduler
Schedule periodic tasks to run asynchronously
-
tenorite
A concurrency abstraction library. Provides a client-server model for asynchronous workers
-
hybrid-logical-clock
Hybrid Logical Clocks for distributed systems
-
quick_crawler
QuickCrawler is a Rust crate that provides a completely async, declarative web crawler with domain-specific request rate-limiting built-in
-
xtra-addons
Add-on functionality (Broker, Registry) for crate xtra
-
deferred
help perform deferred execution of code logic
-
pakr-fsm
Template to implement finite-state-machines
-
random-access-storage
Abstract interface to implement random-access instances
-
pingora-rustls
RusTLS async APIs for Pingora
-
futures-diagnose
Wraps around a Spawn and provides lots of diagnostics
-
futures-net
The futures-net library
-
async-log
Async tracing capabilities for the log crate
-
tokio-childstream
Convert a tokio::process::Child into a Stream for stdout, stderr, and exit events
-
happyeyeballs
Happy Eyeballs implementation in Tokio (not RFC compliant atm)
-
bufstream
Buffered I/O for streams where each read/write half is separately buffered
-
limitation
A rate limiter using a fixed window counter for arbitrary keys, backed by Redis
-
peace_webi_output
Web interface output for the peace automation framework
-
gritlab
Gitlab rust API sdk
-
eyeball-im-util
eyeball-im
-
futures-async-stream
Async stream for Rust and the futures crate
-
buffer-unordered-weighted
Stream::buffer_unordered where each future can have a different weight
-
arti-rpcserver
Backend functionality for Arti's RPC service
-
bastor
A wrapper helps implementing actor with Bastion more easier with self-implemented state
-
tower-util
working with
Service
-
monoio-native-tls
Asynchronous TLS streams wrapper for Monoio based on NativeTLS
-
trale
minimalistic Rust async executor using epoll for efficient, correct task execution
-
specta
Easily export your Rust types to other languages
-
futures-sink
The asynchronous
Sink
trait for the futures-rs library -
async_monad
Asynchronous monad for rust
-
nextgraph
client library. Nextgraph is a decentralized, secure and local-first web 3.0 ecosystem based on Semantic Web and CRDTs
-
reception
creating TCP listeners that spawns clients providing model abstraction layer
-
loading-bytes
Load bytes from paths on native and WASM
-
teloxide-core
Core part of the
teloxide
library - telegram bot API client -
pi_async_file
A async file tools library
-
maybe-future
Future that can be None
-
io_tee
Tee Read, BufRead, and Seek instances to a writer
-
contained-actors
contained is a research project implementing the proposed harmonic runtime for orchestrating cloud-native systems
-
mikrotik_api
& minimal client to connect and interact with Mikrotik RouterOS API, usually exposed on port 8728
-
blec
cross-platform ble client library based on btleplug
-
evdev-shortcut
Global shortcuts using evdev
-
zstd-framed
zstd seekable format compression and decompression. Supports sync and async I/O
-
overclock
A framework for building data-driven distributed systems
-
stream_generator
Allows to easily generate streams with async/await
-
enstream
Conversion from Future to Stream
-
zeebe
client for defining, orchestrating, and monitoring business processes across microservices using Zeebe
-
reqchan
channel for requesting and receiving data. Each channel has only one requesting end, but it can have multiple responding ends. It is useful for implementing work sharing. The two ends…
-
txn
A generic optimistic transaction manger, which is ACID, concurrent with SSI (Serializable Snapshot Isolation)
-
tidy-browser
Tidy up browser information
-
abort-on-drop
A wrapper of Tokio's JoinHandle that aborts the task when it's dropped, while still allowing it to be awaited for joining
-
tokio-easy-timer
A tokio-based task scheduler, with a user-friendly API
-
futures-await-test
Async test support for Rust through a procedural macro. This crate defines the
#[async_test]
attribute to make writing tests that use async/await easier. -
blocking-permit
Permits and a thread pool for blocking operations
-
viz-utils
Viz utils
-
futures-ticker
An asynchronous recurring time event
-
rusty_tarantool
Tarantul async client based on tokio framework
-
fut_rwlock
A read-write lock that is read and written via Futures
-
async_dataloader
Powerful tool for avoiding N+1 queries using async/await, based on the DataLoader pattern
-
dyn-timeout
Dynamic timeout, cancel, add and remove time before a callback execution
-
acril-rt
A lightweight single-threaded runtime for Acril actors
-
space-traders
Async SpaceTraders API client for Rust
-
deadpool-lapin
Dead simple async pool for lapin
-
async-variadic
async variadic functions in Rust with trait bounds
-
agner-sup
An actor toolkit inspired by Erlang/OTP (supervisors)
-
async-raft
An async implementation of the Raft distributed consensus protocol
-
gossip-relay-picker
A relay picker for nostr, used by gossip
-
epicenter
synchronous and asynchronous event dispatcher for Rust
-
async-select-all
A futures library adapter for selecting over a list of futures
-
stream-kmerge
K-way merge for streams
-
io-tubes
functionality like pwntools tube for async io in rust
-
paho-mqtt-sys
Low-level, unsafe Rust wrapper for the Paho MQTT C Client Library. This is part of the official Eclipse Paho Rust Client Library
-
salvia
Incremental computing brought to async Rust
-
rtx
zero-cost runtime-abstraction intended for use by Rust libraries to enable the Freedom of Choice between asynchronous runtimes
-
paperless-rs
An asynchronous Rust library for the Paperless-ngx document manager
-
git-event
Customizable event handler for updates in remote git repositories
-
srmw
Asynchronous single-reader, multi-writer
-
hypixel
Rust wrapper for the Hypixel public API
-
fluvio-async-tls
Asynchronous TLS/SSL streams using Rustls
-
multiqueue
A fast mpmc broadcast queue
-
fundamentum-sdk-api
HTTP client targeting Fundamentum IoT devices RestAPI
-
async-http1-lite
Asynchronous http1 stream
-
parallel-stream
Data parallelism library for async-std
-
async-jobs
Asynchronous job orchestration for Rust
-
patoka
Try this if you can decompose your problem into actors
-
russh-agent
Asynchronous ssh-agent client
-
rad
A type-safe, high-level interface to librados using the low-level C bindings from ceph-rust
-
alopecosa
Pure rust async Tarantool 1.6+ connector built on tokio
-
switchboard
Enables inter-process communiucation via queues and wakers
-
eventsource-stream
A basic building block for building an Eventsource from a Stream of bytes
-
rmw_ttlmap
Minimal async cache in Rust with support for key expirations
-
futures-stream-ext
Asynchronous stream extensions for the futures(-core) crate
-
gidle_future
A future executor for the glib main loop idle time
-
simple_futures
futures for use in async operations
-
haiyuu
experimental actor-like library
-
raftlog
distributed replicated log based on the Raft algorithm
-
zookeeper-cache-rust
ZooKeeper client cache
-
newsblur_api
NewsBlur-API
-
slog-scope-futures
slog-scope for
Future
s -
hala-future
hala asynchronous programming primitive types
-
safina-timer
Safe async timers - ARCHIVED: Code moved to
safina
crate -
toy-async-runtime
Toy library to start to work with async rust, build for reckless person!
-
terrars-integrations-github
Pre-generated Terrars Github bindings
-
clap-and-async-test
Is a example to use clap with tokio and futures, how run concurrently some functions with a loop inside
-
enfync
Environment-friendly async utilities
-
intercomm
Asynchronous inter-component communication library
-
elfo-configurer
Loads and distributes configs across the elfo system
-
laizy
stable and thread-safe implementation of a lazy value
-
tokio-stomp
Asynchronous streaming STOMP client
-
signalfut
A future similar to tokio::signal::unix::Signal, but can be used with all the runtimes
-
vexide-async
The async executor at the core of vexide
-
blockz-futures
working with futures for the tokio stack
-
mini-c-ares
A minimal Rust wrapper for the c-ares library, for asynchronous DNS requests, based on rust-c-ares
-
f289ctrl
Communication library for Fluke 289 digital multimeter
-
abcperf-minbft
Integration of MinBFT into ABCperf
-
async-raft-ext
An async implementation of the Raft distributed consensus protocol.The ability of raft is enhanced while keeping the access interface unchanged for rnacos
-
async-anyhow-logger
An easy crate for catching anyhow errors from an asynchronous function, and passing them to your logger
-
eventually-postgres
Event Store implementation using PostgreSQL for the Eventually crate
-
corcovado
Non-blocking IO library
-
boomerang_builder
The Reactor assembly API for Boomerang
-
async-refresh
Create values that refresh automatically and asynchronously after a given duration
-
mak
but mak it faster
-
orengine
Optimized ring engine for Rust. It is a lighter and faster asynchronous library than tokio-rs, async-std, may, and even smol
-
lelet
golang like task executor
-
sparkle-impostor
A third party crate for Twilight to execute Discord webhooks that clone an existing message
-
spaad
Zero boilerplate actor systems with xtra
-
signalr_rs
SignalR client based on actix web client and async await
-
future-clicker
Reimplementation of manual_future without using
futures
unstable -
awesome-operates
A reposity includs many common use code utils
-
unblock
A thread pool for isolating blocking in async programs
-
mio-uds
Unix domain socket bindings for mio
-
taski
async task DAG execution
-
agnostic-lite
agnostic-lite
is WASM friendly and light version ofagnostic
, for users who want to write async runtime-agnostic crate -
try-again
Retry synchronous and asynchronous operations
-
pseudoterminal
A cross-platform pseudoterminal implementation with async support
-
qp
Quick Pool: High Performance Async Generic Pool
-
stream-ext
An extension trait for Streams that provides a variety of convenient combinator functions
-
crown
jewel of rust libraries
-
arta-tokio
Async abstractions implementation for Tokio
-
io-tether
Traits for defining I/O objects which automatically reconnect upon failure
-
tasc
A minimnal, asynchronous threadpool
-
gabelung
Branch an asynchronous stream of cloneable items into two
-
patchable-async-sleep
An async sleep function, patchable to the preferred runtime
-
dwbhk
dwbhk-rs is a library for working with Discord Webhooks
-
ndless-async
Ndless-specific integration with async/await for the TI-Nspire
-
tokio-duplex
Combine seperate
AsyncRead
andAsyncWrite
types into a singleAsyncRead + AsyncWrite
type -
agreed
Fork of async-raft, the Tokio-based Rust implementation of the Raft protocol
-
ringbuf-rs
in-memory ringbuf implementation
-
mrwei
that implements the common promise primitive for rust based on std future
-
raft-lite
understandable implementation of Raft consensus algorithm
-
rs-copier
Copy and move files asynchronously
-
serial-io
A serial port implementation
-
simple-middleware
General purpose middleware crate
-
promise
future/promise library for rust
-
mlua_actor
Lua Actor for Rust(sync/async)
-
tokio-socketcan-bcm
Asynchronous Linux SocketCAN - Broadcast Manager support (BCM) with tokio
-
tokio-scoped
Scoped Runtime for tokio
-
qbit-api-rs
A asynchronous Rust wrapper for qBittorrent Web API
-
rust_howto
A documentation summary and a compendium of snippets and recipes for the Rust language and ecosystem. Everything you need for day-to-day Rust coding, all in one place.
-
glib-signal
GObject signal bindings
-
atticus
A mimimal API to create asynchronous actors
-
parallel-future
fluent async task experiments
-
async-dropper-simple
struct-wrapper (i.e. AsyncDropper<T>) based implementation of AsyncDrop
-
quickwit-actors
Actor framework used in quickwit
-
interval_future
Wraps a synchronous, waker-less polling function in an interval-based future
-
wag
Go like sync.WaitGroup implementation in Rust. (sync/async)
-
lib3h_zombie_actor
lib3h actor request tracking module
-
actix-storage-sled
actix-storage based on sled
-
crate-test-xxx
test crate
-
andiskaz
A convenience library for writing games and other apps in TUI
-
ert
A combinator to control future execution order
-
future_handles
complete futures via handles
-
fluke-io-uring-async
An abstraction on top of io-uring
-
eventador
lock-free pub/sub event-bus with sync and async APIs
-
taps
taps (Tokio Asynchronous Pub/Sub) is an in-process async message broker that can be used for messaging between spawned tokio tasks
-
amqp
AMQP/RabbitMQ protocol client
-
pick_action_from_image
Pick an action from an image
-
gcs-rsync
rsync support for gcs with higher perf than gsutil rsync
-
bb8-bolt
A bolt-client adaptor for the bb8 connection pool
-
async_timing_util
tokio async functions for waiting until even intervals (on 1 min, 5 min, 30 min, etc), or waiting until a specified timestamp
-
service-io
Build your service-server fast, easy (and without hosting!)
-
oc-wasm-futures
Futures that allow async/await to be used in OC-Wasm for a more ergonomic experience
-
openraft-rocksstore
A rocksdb based implementation of the
openraft::RaftStorage
trait -
tourniquet-celery
Async native round-robin manager for remote services. celery integration.
-
stellwerksim
Rust SDK for StellwerkSim
-
fb-api
Facebook Api abstraction for async rust
-
tokio-stomp-rs-rs
Asynchronous streaming STOMP client fork
-
sidekiq-rs
Sidekiq compatible server in Rust
-
futwaiter
The container of Future's that has the ability to complete them all at once
-
rxqlite-common
A distributed sqlite database built upon
openraft
,sqlx
andsqlite
-
histlog
hdrhistogram crate, provides off-thread serialization of HdrHistogram interval logs to file
-
futures-zmq
Futures abstractions for ZeroMQ on any futures executor
-
crb-pipeline
CRB | Composable Runtime Blocks | Pipeline
-
epoxy_streams
Base streams implementation for the
epoxy_frp
library. Please use epoxy_frp instead. -
rustpub
Activitypub types
-
completion
writing completion-based asynchronous code
-
futures-test-preview
Common utilities for testing components built off futures-rs
-
tokio-process-stream
that wraps a tokio::process into a tokio::stream
-
tokio_interval
基于Tokio实现了 setInterval(callback, ms) 和 setTimeout(callback, ms) 类似于Javascript的API
-
tag_nominatim
Bindings to the reverse geocoding API powered by openstreetmap
-
strawpoll
A wrapper to avoid spurious polling
-
retry_fn
retry function with versions for blocking or non-blocking, tokio or async-std
-
change_stream
A Stream that only emits if the value is different
-
cdrs-tokio
Async Cassandra DB driver written in Rust
-
settimeout
Creates a std::future::Future implementation to be ready at some point
-
async_chanx
Implement
Sink
for some channel implementations -
scoped_async_spawn
spawn non-static futures
-
async-rayon
Mix async code with CPU-heavy thread pools using Futures + Rayon
-
retry_future
Retry futures mechanism
-
rivulet
Asynchronous contiguous-memory streams
-
webrocket
A closure focused WebSocket server implementation
-
log-tracing-layer
Build your own custom tracing layer
-
italo-api
Rust binding for Italo API
-
tokio-rustls-fork-shadow-tls
Asynchronous TLS streams wrapper for Tokio based on Rustls
-
cancellable
providing a generic cancellable utility
-
qcow2-rs
read/write qcow2 image in async/await
-
gcp_auth
Google cloud platform (GCP) authentication using default and custom service accounts
-
mqi
Idiomatic IBM® MQ Interface (MQI) and MQ Administration Interface (MQAI) APIs
-
future-combinator-params
functions to inject extra arguments between futures combinators Then/AndThen
-
select-next-any
Alternative to futures::StreamExt::select_next_some that returns the None variant
-
samotop
SMTP server and library built on async-std
-
tinkoffpay
tinkoff integration (the seller receives a link to the payment form and redirect the buyer to it); NB: with callback method
-
broadcaster
Broadcasting futures mpmc channel
-
reactors
Performance-focused cross-platform asynchronous IO implementation
-
messagebird-async
Wrapper around the message bird SMS API
-
fsdr-blocks
Building blocks for FutureSDR signal processing library for SDR and real-time DSP
-
mm1-common
M/M/1! Queueing, do you speak it?!
-
pipestream
Async support for pipe or something has file descriptor
-
page-turner
A generic abstraction of APIs with pagination
-
futures-util-either
futures_util::future::Either Ext
-
wgp
waitgroup implementation
-
cooper
in-process, async Actor library for Rust
-
lnd_grpc_rust
An async library implementing LND RPC via tonic_openssl and prost
-
ruva
Event Driven Message Handling
-
compio-fs
Filesystem IO for compio
-
callback-future
Adapter between callbacks and futures
-
peermerge
Manage JSON-like documents with multiple writers, without a central authority, using a P2P protocol
-
swimos_downlink
SwimOS Downlink Runtime
-
kompact-component-derive
A derive macro for Kompact component definitions
-
stackful
Bridge between sync and async
-
kythera-fvm
Core implementation of the Kythera FVM
-
alligator
getting the output value from a future
-
yaanhyy_rust
cargo mod example
-
tokio-reactor-trait
reactor-trait implementation for tokio
-
tokio-nsq
NSQ client built on Tokio. Tokio NSQ aims to be a feature complete NSQ client implementation.
-
allochronic-util
Private utility crate for allochronic and khonsulabs
-
catty
Send and await a value asynchronously
-
axiom
Implements a highly-scalable and ergonomic actor system for Rust based on the best of Erlang / Elixir and Akka
-
sched-clock
A timer for task scheduling
-
tower-actor
A
tower
middleware that creates aService
by passing messages to an actor -
termion-input-tokio
An adapter that exposes termion's input and key event iterators as asynchronous streams
-
heim-common
Common stuff shared across heim project crates
-
deploy
The
deploy
library to aide writing and debugging of distributed programs, as well as tooling to run them across a cluster -
discord_api
Interact with the Discord API from your shell
-
medina
An asynchronous web crawling engine
-
relm
Asynchronous, GTK+-based, GUI library, inspired by Elm, written in Rust
-
simple-async-pipe
Aims to provide a simple pipe-like functionality for async code
-
rfm69-async
async driver for the rfm69 radio transceiver
-
async-timers
asynchronous timer primitives
-
tokio-rustls-wasi
Asynchronous TLS/SSL streams for Tokio using Rustls
-
async-cuda-npp
Async NVIDIA Performance Primitives for Rust
-
peachy
async task manager, similar to thread pool but cooler and for structs
-
delimiter-slice
Stream type for splitting a delimited stream
-
futures-time
async time combinators
-
fut-compat
Offers compatibility between the tokio and async_std runtimes
-
futures-io-preview
The
AsyncRead
andAsyncWrite
traits for the futures-rs library -
promises
Effective, simple, lightweight Javascript promises in Rust
-
async-dispatcher
async runtime based on a pluggable dispatcher
-
openai-api-fork
OpenAI API library for rust
-
sync_stream
Aggregate multiple streams by polling stream items in order, keeping the consumption of multiple streams in sync
-
broker-tokio
tokio for broker
-
rust-with-kafka-tls
Rust messaging with a Strimzi Kafka cluster secured with self-signed tls assets for encryption in transit with mTLS for client authentication
-
future-by-example
Examples of common patterns using Future
-
nonblock
Read available data from file descriptors without blocking (e.g. sockets, streams, child stdout, named pipes)
-
django-query
Tools for mocking Django-style endpoints
-
async_closure
utilizes the nightly-only feature async_fn_in_trait to imitate async_closures
-
async_msp_lib
Async msp library for iNav and BetaFlight
-
libsync
containing channels and other synchronisation object implementations
-
containerd-snapshots
Remote snapshotter extension for containerd
-
tcp-channel-client
Asynchronous tcpclient based on aqueue actor
-
sender-sink
classes for working with tokio UnboundedSender and the Sink trait
-
amqp-lapin-helper
rust lapin helper
-
xo-api-client
Unofficial crate for accessing Xen Orchestra through its API
-
async-file-lock
Asynchronous file lock that can auto lock and auto seek
-
ardop_interface
Interface to the Amateur Radio Digital Open Protocol (ARDOP)
-
atcoder
A template for Rust project
-
tezaursapi
api wrapper for tezaurs.lv
-
scoped_tasks_prototype
A quick-and-dirty attempt to get scoped tasks in Rust
-
async-openai
OpenAI
-
encrypted-dns
A modern encrypted DNS server (DNSCrypt v2, Anonymized DNSCrypt, DoH)
-
rseip-cip
common industry protocol for rseip
-
enjoin
Powerful syntax-level async join macro
-
future-utils
Extensions to Rust's Future and Stream traits
-
xactor
actors framework based on async-std
-
noosphere-fs
A high-level, FS-like view over Noosphere content
-
anotify
Async iNotify Filesystem Watcher
-
asyncs
async runtime agnostic facilities
-
catalyzer
HTTP server framework
-
augrim
consensus algorithms implemented in Rust
-
hermod
futures-based RSS/Atom library
-
restartables
Future that restarts an inner future if it doesn't meet a condition
-
async_progress
Create sync points across async tasks
-
salvo-serde-util
serde util for salvo
-
ssip-client-async
Client API for Speech Dispatcher
-
cf-turnstile
client for Cloudflare Turnstile
-
streams
A collection of stream-extensions that are missing in the
futures
crate -
batchloader
A type-safe async request batcher based on facebook's dataloader
-
joyent-tokio-zookeeper
Asynchronous client library for interacting with Apache ZooKeeper
-
try_future
Convenient short-hand for returning early from
futures
-based functions -
heim-sensors
Cross-platform sensors information
-
typout
Command-line typewriter output stream
-
jarust
A janus client SDK in Rust
-
mqttc
client for the MQTT protocol
-
qsdr-benchmarks
Benchmarks for qsdr experimental high-performance SDR runtime
-
medea-reactive
Reactive mutable data containers
-
async-lease
Essentially a futures-oriented Arc<Mutex<Option<T>>>
-
serenity_ctrlc
Ctrl+C handler for serenity
-
async-signal
Async signal handling
-
north-config
North config is a multi source configuration crate designed as part of the North Microservice Framework
-
appliance
A lightweight framework to build async-friendly components with message-based intercommunications
-
unsync
Unsynchronized synchronization primitives for async Rust
-
simple-tokio-watchdog
Pretty simple but bulletproof watchdog actor
-
c_mcai_worker_sdk
AMQP Worker to listen and provide trait to process message
-
scd4x-rs
query SCD4x sensors over I²C
-
pingora-runtime
Multithreaded Tokio runtime with the option of disabling work stealing
-
embedded-executor
Embedded systems-friendly
Futures
executor -
starstruck
A game building utility that is made to be simple to use while still providing great performance
-
releez
run application release-checklist safely
-
otdb
An open trivia database API wrapper
-
thread-async
Execute a task in a new thread and await the result asynchronously
-
connection-utils
Connection related utilities
-
futura
Helpers for working with futures
-
async-read-progress
Extension traits for inspecting
AsyncRead
progress -
elfo-test
Test utils for the elfo system
-
async-ops
Use std::ops traits with Futures
-
manual_future
A future that must be manually completed, similar to Java's CompletableFuture
-
nakadion
Types for interacting with the Nakadi Event Broker
-
async_tasks_state_map
A struct for recording execution status of async tasks with async methods
-
rust-moysklad
Framework for moy sklad
-
puteketeke
An asynchronous runtime built on smol
-
croissant
A scheduling library
-
dynamodb-mutex
Use Dymanodb mutex library
-
ruw
Read-Update-Write
-
dbus-async
Asynchronous DBus library
-
futures-finally
that executes a future after the completion of a future or stream regardless of the value or outcome
-
browser-window
optionally async, optionally threadsafe, electron-like browser toolkit for Rust
-
linkd
actor model framework that takes inspiration from OTP in the erlang ecosystem
-
rustmark
Extensible web application for serving Markdown-based content
-
lunatic-distributed
Node to node communication
-
awaitgroup
Wait for a collection of async tasks to finish
-
foxhole-api
wrapper for the Foxhole War API
-
hydrolink
Lavalink client made with tokio independent of the Discord library, used in production by Hydrogen
-
aktors
Driver for derive-aktor
-
stateful_async_worker
Asynchronous stateful worker threads utilizable as futures
-
eventsourcing
Event Sourcing for Rust
-
stream-operators
a collection of selected rxjs operators for rust standard Stream
-
wasmflow-streams
encapsulating the message packets sent across Wasmflow components
-
libp2p
Peer-to-peer networking library
-
async-openai-wasm
OpenAI on WASM
-
thread_runner
executing tasks concurrently
-
rexer
Async I/O multiplexing library for rust
-
async-result
wrapper providing a convenient way to await a result, built on futures-channel's oneshot channel
-
idb
A futures based crate for interacting with IndexedDB on browsers using webassembly
-
rusty-gql
Schema first GraphQL Library for Rust
-
sctp-proto
A pure Rust implementation of SCTP in Sans-IO style
-
repsheet_etl
ETL tools for repsheet
-
stream-download
streaming content to a local file-backed cache
-
par_io
Parallel, async file I/O library with control over memory usage with no dependencies
-
unsend
A thread unsafe runtime for thread unsafe people
-
remote_config
Flexible crate for asynchronously loading configuration from remote source with caching and automatic revalidation
-
uds
A unix domain socket crate that supports abstract addresses, fd-passing and seqpacket sockets
-
emitter_runtime
Runtime support for rs-event-emitter
-
tokio_telegraf
Minimal async rust wrapper for the telegraf/influxdb protocol, based on Tokio
-
tokio-uring-rustls
Integrate rustls into tokio-uring
-
ferris_chats_data
data structures for ferris_chat
-
projections
Macro-free pin projections because why not?
-
wookie
Async test/bench toolkit including single stepping executors. No-std compatible.
-
futures-task
Tools for working with tasks
-
gen-stream
Generator-based streams for Rust and futures 0.3
-
cdp-html-shot
capturing HTML screenshots using CDP
-
simple_spawn_blocking
spawning blocking tasks more ergonomic
-
cloudflare_dyndns
DynDNS client for Cloudflare
-
init_system
Framework to wrap application init
-
actor-interfaces
I only uploaded this to crates.io because I was having some issues cross compiling with local dependencies. If anyone wants to use the name for something actually useful, DM me on github
-
tokio-agent
Agents are a simple abstraction around state, inspired by Elixir's Agent
-
bongonet-timeout
Highly efficient async timer and timeout system for Tokio runtimes
-
futures-cache
Futures-aware cache backed by sled
-
scuttlebutt
interface for kubernetes events
-
async-handle
A reference-counted async RwLock
-
lib-wc
Will's Programming Toolbox
-
tl-async-runtime
A bad runtime impl for educational purposes only
-
fbinit-tokio
detail of fbinit crate
-
eventific
that gives you the needed building blocks for event sourcing
-
tokio-tun
Asynchronous allocation of TUN/TAP devices using tokio
-
go-zoom-kinesis
A robust AWS Kinesis stream processor with checkpointing and retry capabilities
-
futures-promises
Promises and Watched Variables for Futures
-
graus-db
A high-performance, thread-safe key-value embedded data store
-
rsdns
DNS Client Library
-
suppaftp-cli
FTP command line client, based on suppaftp
-
swimos_messages
SwimOS Runtime Internal Messaging Protocol
-
jittr
A binary heap based jitter buffer implementation for zero latency udp/rtp streams
-
peace_webi_components
Web interface components for the peace automation framework
-
async_io_utilities
An asynchronous IO utilities crate powered by
tokio
-
execution-engine
Toca Execution Engine implemented using Futures and async/await
-
simplex-chat
API for the SimpleX Chat CLI
-
image_search
designed to search Google Images based on provided arguments
-
async-ringbuffer
A nonblocking spsc ring buffer with fixed capacity
-
async-zeroconf
Async library for wrapping Zeroconf implemenations for use with Tokio
-
mutex-extra
RefMutex<T>
that is similar toMutex<T>
but isSync
andSend
even ifT
isn’tSend
-
geph4-aioutils
geph4
-
gnostr-core
Replication protocol for Hypercore feeds
-
back-to-the-future
Conversions between std::future::Future and futures::Future
-
tokio-pty-process-stream
wraps tokio-pty-process in order to provide a simpler API as a single stream object
-
yew-interop
use javascript and css asynchrously in yew
-
tokio-stomp-2
Unofficial successor to Asynchronous streaming STOMP client
-
genserver
Elixir inspired async actor library
-
twitch_comment_stream
stream comments from Twitch
-
mysql_async
Tokio based asynchronous MySql client library
-
bluest
A cross-platform Bluetooth Low Energy (BLE) library
-
amqp-manager
Lapin wrapper that encapsulates the use of connections/channels and creation of amqp objects
-
lapin-tower-worker
Framework for building AMQP workers with lapin and tower
-
iterstream
Converts Iterator into real asynchronous Stream
-
vkteams-bot-cli
VK Teams Bot API CLI
-
mfio
Flexible completion I/O primitives
-
async-graphql-relay
Relay support for async-graphql
-
hitbox-actix
Asynchronous caching framework for Actix
-
lwactors
Lightweight actors for Rust using futures-rs
-
tracing-layer-slack
Send filtered tracing events to Slack
-
tokio-anon-pipe
Asynchronous anonymous pipe for Windows
-
async-cron-scheduler
Runtime-agnostic async task scheduler with cron expression support
-
tokio-xmpp
Asynchronous XMPP for Rust with tokio
-
hentai
API wrapper for nhentai.net
-
lagoinha
package that uses public APIs to fetch addresses using the Brazilian Postal Code (CEP). This package cuncurrenlty calls all the supported APIs and returns the first result.
-
mio-signals
handling signals with Mio
-
dbus-async-derive
Handler trait derive macro for dbus-async
-
set_timeout
allows efficiently executing futures after some delay has passed
-
crypto-auditing
Client library for crypto-auditing project
-
bacon-ls
Bacon Language Server
-
futuresdr-types
Polymorphic Types for an Experimental Async SDR Runtime for Heterogeneous Architectures
-
af-core
A core library and async runtime for Rust applications
-
mailbox_processor
A small little actor abstraction inspired by the FSharp Mailbox Processor which in turn was inspired by erlang
-
tokio-task-queue
Execute futures from a stream of futures in order in a Tokio task
-
oricalchum
A lightweight actor model
-
black-box
A minimal actor framework
-
suspend
A common mechanism for suspending a thread or a Future until notified
-
v_queue
file based queue
-
lemmy_apub_lib
A link aggregator for the fediverse
-
tokio-tasks
Task managment for tokio
-
deduplicate
caching, asynchronous, request deduplication
-
ockam_node_no_std
Ockam library types that do not need
std
-
salvo-oapi
OpenApi support for Salvo web framework
-
openraft-rocksstore-compat07
A example v07 compatible implementation of the
openraft::RaftStorage
trait -
tokio-stream_wasi
work with
Stream
andtokio
-
asynciter
Asynchronous iterator
-
tokio-netstring-trait
A trait for tokios AsyncRead to easily read netstrings from streams
-
futures-state-stream
A version of the futures crate's Stream which returns state on completion
-
async-native-tls-2
Native TLS using futures
-
streamtools
Additional stream combinators
-
heph-rt
speciailised runtime for Heph's actor
-
streamify
Conversions from values to Stream
-
icanhazdadjoke-sdk
An SDK to interact with the icanhazdadjoke Dad Jokes API
-
rexecutor
A robust job processing library
-
rust-cli-commands
-
baildon-store
B+Tree CLI
-
trillium-tokio
tokio runtime adapter for trillium.rs
-
mias_channel
that supports bi-directional channels by wrapping others
-
asygnal
[WIP] Async-first signal handling, such as ctrl-c
-
flysystem
A filesystem abstraction layer for Rust
-
mailfred
Process emails as an HTTP server
-
gandi-v5-livedns-api
Gandi LiveDNS Api
-
ipc-orchestrator
Orchestion of command line processes for local dev usage with IPC communication
-
nasu
Command-line utility which poll on remote addresses in order to perform status checks periodically
-
pinarcmutex
PinArcMutex
type, for shared mutable access to pinned data -
conquer-struct
macros to perform concurrent future resolution, while populating struct fields
-
hyper-multipart-rfc7578
multipart/form-data (RFC7578) for Hyper
-
pi_weight_task
任务池
-
duplexify
Combine a reader + writer into a duplex of Read + Write
-
jenner
Tools for working with generators to work with both iterators and streams
-
monoio-io-wrapper
A read/write wrapper to bridge sync and async io
-
tower-pipeline
A Tower Service combinator that "pipelines" two services
-
openrazer
Asynchronous bindings to the OpenRazer daemon
-
ebus
Basic Event Bus implementation
-
dummy-waker
Get a
core::task::Waker
that does absolutely nothing -
quicksink
Create a Sink from some value and a closure returning a Future
-
neo-email
The modern way to build emails services with Rust
-
tokio-sync2async
Helpers to bridge between sync and async code
-
plctag-async
async wrapper for libplctag
-
register-count
Counting
Register
s created by aCounter
-
tripwire
makes futures pre-emptible
-
hash_events
An MPMC event system that allows for custom events. Events are emitted with a payload, and subscribers to that event are stream of payloads. For each event, all subscribers are triggered.
-
osaka
async for rust without the noise
-
poolparty
Added functionality for the
futures::executor::ThreadPool
futures executor -
smelling_salts
Abstraction over OS APIs to handle asynchronous device waking
-
tokio-global
Global tokio runtime
-
libuio
A io_uring based async framework designed for high performance networking on linux
-
tower-limit
Limit maximum request rate to a
Service
-
tower-sessions-sqlx-store
SQLx session stores for
tower-sessions
-
vino-packet
encapsulating the message packets sent across Vino components
-
channels-io
Async agnostic/Sync IO & buffer management abstractions
-
intervalier
Interval events with handling notifications
-
Agentic-rs
agents
package provides a set of tools for creating and managing agents capable of processing text and performing specified tasks based on a given role. It leverages asynchronous… -
rasio-mio
a RASIO drivers implementation base on mio
-
jstime_core
JS Runtime
-
futures-cputask
Turn synchronous CPU-bound tasks into futures
-
euklid
CRDT
-
fluke-maybe-uring
Replicates some tokio-uring types to allow building code without it
-
akinator-py
Python bindings for akinator-rs
-
completeio
Completion based IO drivers and async runtime
-
mobc-forked
A generic connection pool with async/await support
-
edge-nal
Hosts a bunch of traits which are not yet available in the embedded-nal-async crate
-
spin_future
Convert synchronous functions into valid but inefficient futures
-
blocking_pool
A thread pool for running synchronous I/O in asynchronous applications
-
araft
An async raft implementation based on tokio + tonic
-
requiem
Actor framework for Rust
-
underway
⏳ Durable step functions via Postgres
-
iou
io_uring bindings
-
bawawa
Opinionated set of tools to manage and compose process executions
-
limitr
offering various rate-limiting algorithms such as Token Bucket, Leaky Bucket, and more
-
rust-runc
consuming the runc binary in your Rust applications
-
sntpc
making SNTP requests
-
tk-easyloop
A thread local loop and other loop helpers
-
rexa
GraphQL MongoDB API builder
-
atomic-waker
A synchronization primitive for task wakeup
-
lsp-codec
Tokio-compatible codec implementation for Language Server Protocol
-
syncthing
controlling syncthing file synchronization through its REST interface
-
tokio-transports
used for communication between processes
-
futures-mockstream
Minimal mockstream which implements futures async traits
-
slice_ops
A selection of useful slice operations
-
rust-stream-ext-concurrent
Concurrent behavior extensions for any futures::stream::Stream objects
-
asyncfd
Send and receive file descriptors over Unix domain sockets while maintaining Tokio AsyncRead and AsyncWrite
-
fundamentum-edge-pfwd
The port forwarding tool for edge daemon
-
minehut
easy to use Rust wrapper for the Minehut API
-
retry_async
retrying, with specific support for the Azure SDK for Rust (cf. https://github.com/Azure/azure-sdk-for-rust).
-
process-stream
Thin wrapper around [
tokio::process
] to make it streamable -
dtbh_interface
Interface library for the automated scanner
-
mini-tokio
basic asynchronous rust executor
-
batch-renamer
Framework and command line utilities for interactive renaming of a potentially large number of files
-
fates
creating reactive declarations
-
runtime-loop
Runtime loop for Rust
-
coerce-redis
Redis actor persistence provider for Coerce. Supports event sourcing and snapshots
-
async-pipe
Creates an asynchronous piped reader and writer pair using tokio.rs
-
bevy-tokio-tasks
integration of a Tokio runtime into a Bevy app for background processing
-
tokio-shared-udp-socket
Easily share a UDP socket between different futures in tokio
-
deadpool-bolt
A bolt-client manager for the deadpool connection pool
-
indexed_db_futures
Future bindings for IndexedDB via web_sys
-
watchfile
An async utility trait to subscribe to file changes of a serializable file
-
async-hofs
Various extention traits for providing asynchronous higher-order functions
-
atomic-actor
An
Actor
withasync fn
handlers -
paggo
A small, fast, and safe in-memory database
-
todc-net
Algorithms for message-passing (HTTP) distributed systems
-
parabuild
A parallel build utility for template heavy projects
-
hl7-mllp-codec
A Tokio codec for HL7 Minimal Lower Layer Message Transport protocol (MLLP)
-
lease
Object pool that leases values and automatically returns them with async support
-
kvarn-tokio-uring
Temporary Kvarn fork: io-uring support for the Tokio asynchronous runtime
-
futures-loco-protocol
Asynchronous Loco protocol stream for futures
-
bleasy
High-level BLE communication library
-
prokio
An asynchronous runtime compatible with WebAssembly and non-WebAssembly targets
-
makiko
Asynchronous SSH client library in pure Rust
-
gmqtt-client
MQTTv5 client
-
tempest
Realtime message handling framework inspired by Apache Storm and built with Actix
-
itla
ITLA (micro laser) non-blocking control library using embedded-hal
-
bililive
stream-based bilibili live client library
-
tower-fallthrough-filter
A Tower middleware that gives controll to a defined service if the filter matches and otherwise falls through to the inner service
-
leaves
Distributed ID Allocator
-
stick
Platform-agnostic asynchronous gamepad, joystick and flighstick library
-
riker-cqrs
Command Query Responsibility Separation for Riker applications
-
archlinux-repo
Arch Linux repositories parser
-
tokio-prepend-io
Wrapper types that prepends data when reading or writing with AsyncRead or AsyncWrite
-
safina-async-test
Macro for running async tests - ARCHIVED: Code moved to
safina
crate -
mio-anonymous-pipes
Asynchronous wrapper for windows synchronous pipes
-
wd_event
event system
-
f189ctrl
Communication library for Fluke 189 digital multimeter
-
tokio-lock
Access an object from a single Tokio task
-
kapacitor-multi-indicator-batch-udf
A multi-indicator batch UDF for Kapacitor
-
client-handle
A macro to generate client handles when using multithreaded / asynchronous code
-
ianaio-file
Convenience crate for working with JavaScript files and blobs
-
async-native-tls-alpn
Native TLS using futures
-
bme280-rs
query BME280 sensors over I²C
-
stomp
A full STOMP 1.2 client implementation. Allows programs to interact with message queueing services like ActiveMQ and RabbitMQ.
-
tokio-task-tracker
graceful shutdown solution for tokio
-
tus_async_client
native async client library to interact with *tus* enabled endpoints
-
async-rx
functions for async reactive programming
-
gpiocdev
Access GPIO lines on Linux using the GPIO character device
-
stream-utils
Additional stream combinators
-
whorl
was created to teach you how async executors work in Rust
-
retry-strategy
A better asynchronous retry tool based on Tokio
-
ex-futures
An extension of
futures
-
safe-vk
create your own vk bot for conversations
-
async-read-util
A collection of utilities for working with AsyncRead
-
component-future
implements the inner future protocol documented in the tokio docs
-
volo-macros
Volo's proc macros
-
specta-typescript
Export your Rust types to TypeScript
-
futures-shuttle
Futures-aware shuttle synchronization object
-
transform-stream
Lightweight async stream wrapper
-
retainer
Minimal async cache in Rust with support for key expirations
-
async-io-traits
Async versions of io traits
-
email-lib
Cross-platform, asynchronous Rust library to manage emails
-
safina-select
Safe async select function, for awaiting multiple futures - ARCHIVED: Code moved to
safina
crate -
rt-local-core
Thread local asynchronous runtime working with platform-specific event loops
-
egg-mode-extras
Rate-limited streams and other helpers for egg-mode
-
libpool
threadpool from The Rust Programming Language
-
eventually-redis
Event Store implementation using Redis, for Eventually crate
-
tracing-appender
file appenders and making non-blocking writers
-
tokio-resource-pool
A generic resource pool for the Tokio ecosystem
-
async-codec-lite
Adaptors from AsyncRead/AsyncWrite to Stream/Sink using futures
-
continue
Swift-style continuation API
-
monoio-rustls-fork-shadow-tls
Asynchronous TLS streams wrapper for Monoio based on Rustls
-
futures-rate
easy tools to help Rust applications guide critical resources or code paths from being overwhelmed
-
futures-async-combinators
toy futures combinators
-
aral-runtime-tokio
Aral Runtime for tokio
-
deadline
A one-macro crate to ensure assertions meet their deadlines
-
tls-api-2
TLS API without implementation
-
tokio-executor-trait
executor-trait implementation for tokio
-
async-stream-http-tunnel-grader
Asynchronous stream http tunnel grader
-
gen-z
Macro-free stream construction through asynchronous generators via an awaitable sender
-
tarpc
An RPC framework for Rust with a focus on ease of use
-
gneiss-mqtt
Asynchronous and threaded MQTT(5) clients
-
gmf
An RPC library using Glommio and Tonic. Note: This package only works on Linux.
-
oauth-lib
Asynchronous Rust library to deal with OAuth flows
-
xtor
Async Actor framework for Rust which is blazing fast and rock solid
-
ekv
Key-value database for embedded systems, for raw NOR flash, using an LSM-Tree
-
smol-hyper
Integrations between smol and hyper
-
mycelium_lib
Mycelium DDM
-
swait
Blocking on Futures
-
assets
asynchronous asset management
-
sched-callback
async callback scheduling
-
online
📶 Library to check your Internet connectivity
-
forceps
async & on-disk database
-
safina-executor
Safe async runtime executor - ARCHIVED: Code moved to
safina
crate -
py_mcai_worker_sdk
AMQP Worker to listen and provide trait to process message
-
lunatic-registry-api
Lunatic host functions for registering named processes
-
local-spawn-pool
Spawn
!Send
futures in a pool and await for all of them to finish. Standalone alternative totokio::task::LocalSet
. -
acton_test
Testing utilities for Acton agents, providing tools to help in the testing and validation of agent behavior
-
tokio-rustls-acme
Automatic TLS certificate management using rustls
-
futures-option
Extension traits for dealing with optional futures and streams
-
charred
char checking
-
gritea
Gitea API sdk
-
bonsaimq
Message/job queue based on bonsaidb, similar to sqlxmq
-
actix-async-await
Experimental async/await support for Actix
-
blocksr
Drew's Rust library for (clang/objc) blocks
-
tor-general-addr
Generalized socket address type used by Tor
-
rqlite-ha421
An async implementation of a rqlite client
-
reactive-messaging
Reactive client/server communications, focused on high performance
-
rxqlite-lite-common
A distributed sqlite database built upon
openraft
,sqlx
andsqlite
-
mio-utun
Utun bindings for mio
-
axum-server
High level server designed to be used with axum framework
-
ginepro
A client-side gRPC channel implementation for tonic
-
skrillax-stream
Combines skrillax-network crates to work nicely on top of a tokio tcp stream
-
epoxy_frp
The Reactive Glue for Frontend Applications
-
rustls-acme
TLS certificate management and serving using rustls
-
tracing-durations-export
Record and visualize parallelism of tracing spans
-
tor-rpc-connect
Common implementation logic for Arti RPC Connect points
-
agner-helm
An actor toolkit inspired by Erlang/OTP (control panel)
-
async_message_dispatcher
dispatching messages to asynchronous handlers easier
-
signals
A functional-reactive-like library for Rust that allows asynchronous chaining
-
rs-car-ipfs
rs-car wrapper to read files from IPFS trustless gateways
-
cucumber-codegen
Code generation for
cucumber
crate -
gearbox
Excessive tooling for Rust, boosting productivity and operations
-
async-graphql-derive
Macros for async-graphql
-
compio-runtime
High-level runtime for compio
-
dbus-tokio
Makes it possible to use Tokio with D-Bus, which is a bus commonly used on Linux for inter-process communication
-
tokio-extra-macros
Extra proc macros for Tokio
-
promising-future
Promise/Future pairs
-
futures-util-io-peek
AsyncPeek trait
-
tower-sessions-dynamodb-store
AWS DynamoDB session store. Not for direct use; see the
tower-sessions
crate for details. -
redis-asio
Asynchronous Redis driver based on tokio
-
rocketmq-store
Unofficial Rust implementation of Apache RocketMQ
-
tonic_lnd
An async library implementing LND RPC via tonic and prost
-
async-raft2
An async implementation of the Raft distributed consensus protocol
-
eventastic
opinionated fork of Eventually-rs. It enforces the use of transactions and handles idempotency.
-
async-stream-tls-upgrader
Asynchronous stream tls upgrader
-
gdext_coroutines
Run Rust Async functions and Coroutines in Godot 4.2+ (through GDExtension), inspired on Unity's Coroutines design
-
worst-executor
A spin-loop like executor for async
-
medusa-zip
A command-line interface to high-performance parallelized implementations of common zip file operations
-
activitystreams-traits
Traits for ActivityStreams 2.0 objects
-
actix-raft
Raft distributed consensus protocol using the Actix actor framework
-
agent_rt
agent scheduling
-
kompact-actor-derive
A derive macro for Kompact Actors
-
mio-extras
Extra components for use with Mio
-
task-exec-queue
A asynchronous task execution queue
-
nanopore
A minimalist async runtime based on io_uring (Linux) and I/O rings (Windows)
-
pinned
Synchronisation primitives for !Send tasks
-
tokio-utun
Utun bindings for Tokio
-
abs_art
ABStraction of Asynchronous RunTime
-
basu
Eventbus crate with sync and async features
-
peace_webi_rt
Web interface runtime data types for the peace automation framework
-
noosphere-core
Core data types of the Rust Noosphere implementation
-
spawn_groups
Structured concurrency construct written in Rust, for Rustaceans
-
hala-io
hala asynchronous io programming primitive types
-
tower-async-hyper
Bridges a
tower-async
Service
to be used within ahyper
(1.x) environment -
app-queue
In-app persistent queue for asynchronous jobs
-
v_exchanges_api_generics
A client for HTTP/HTTPS/WebSocket APIs
-
june
ergonomic remote actors via actix and canary
-
wait-for-me
Async CountDownLatch
-
cute-async
Cute async utilities
-
smol-macros
Macros for setting up a smol runtime
-
async-http-body
Agit init HttpBody Support Async Expressions
-
callysto-avro
Avro serde for Callysto Stream Processing Framework
-
handy_async
A handy library for describing asynchronous code declaratively
-
ratchet_rs
Async WebSocket implementation
-
message_worker
Message Worker is a low-ish level library for Rust for the creation of event-listeners using futures and streams. Notably MW supports non-sync and non-send (i.e. non-thread-safe) contexts within listeners.
-
yield-now
Wakes current task and returns Poll::Pending once
-
sealrs
Set of classic asynchronous primitives (Actors, Executors, Futures / Promises)
-
async-pidfd-next
Process file descriptors (pidfd) for Linux
-
tokio-async-std
An async-std that can fit into tokio ecosystem straight ahead
-
coerce-k8s
Kubernetes discovery provider, automatically discover cluster peers hosted in Kubernetes, based on a configurable pod-selection label
-
async-task-ffi
Task abstraction for building executors
-
interprocess-docfix
Interprocess communication toolkit. Docs fixed.
-
svix-webhook-with-clone
Svix webhooks API client with derive Clone added to Webhook struct
-
orcinus
async-ready mysql protocol implementation / wrapper libraries
-
tokio-async-write-utility
Some helper functions for types impl AsyncWrite
-
limited-join
A zero-dependency crate providing a join future with limited concurrency
-
must-done
An experimental Future that is guaranteed to be done
-
local-pool-with-id
A minor variation on a LocalPool executor which exposes unique IDs for tracking future completion
-
dioxus-query
Fully-typed, async, reusable cached state management for Dioxus 🧬
-
stewart-utils
Small common utilities for stewart
-
asyncore
-
kay
Experimental high-performance actor system framework for Rust
-
swimos_runtime
SwimOS Agent & Downlink Runtime
-
async-drop-guard
offers hash map and cache data structures where individual entries can be locked
-
asyncs-sync
Asynchronous runtime agnostic synchronization utilities
-
some_local_executor
local executor
-
posturn
Build turn-based games with
async
Rust -
futures-await-test-preview
Async test support for Rust through a procedural macro. This crate defines the
#[async_test]
attribute to make writing tests that use async/await easier. -
message-sink
Message framing for AsyncRead + AsyncWrite
-
thespis
The interface of the thespis actor model (contains only traits)
-
grpcio
language implementation of gRPC, base on the gRPC c core library
-
incoming
Trait for taking ownership of a stream of incoming connections
-
volo-grpc
gRPC framework implementation of volo
-
async-read-length-limit
limit the size of an async read
-
join
Macros which provide useful shortcut combinators, combine sync/async chains, support single and multi thread (sync/async) step by step execution of branches, transform tuple of results in result of tuple
-
async_repeat
Retry futures mechanism
-
noop-waker
A waker that does nothing
-
compio-buf
Buffer trait for completion based async IO
-
fd-queue
support fd passing on Unix sockets
-
tk-bufstream
A buffered stream backed by contiguous buffers (netbuf) for tokio
-
async-component-components
async-component components
-
async_object
Async Object wrapper
-
async-entry
extended Tokio's proc macros
-
mediatrix
Strongly typed, extensible event mediator
-
heim-virt
Cross-platform virtualization system detection
-
tokio-mockstream
A fake stream for testing network applications backed by buffers
-
client-util
Help you to build requests and handle responses by several extension trait!
-
wtx
A collection of different transport implementations and related tools focused primarily on web technologies
-
serviceless
actor model in rust, like actix
-
crb-task
CRB | Composable Runtime Blocks | Task
-
and-then-concurrent
Concurrent and-then combinator for Rust streams
-
garcon
A collection of trait and classes to make your thread or async function wait
-
stun-client
async_std based asynchronous STUN client library
-
azur
A no_std Rust crate that implements an executor/reactor and futures using io_uring
-
tower-sessions-file-store
Store sessions for Tower Session store on the file system
-
axum-serde
multiple serde-based extractors / responses for the Axum web framework, also offers a macro to easily customize extractors / responses
-
stalk
sending serialized data with tokio
-
futures-async-runtime-preview
Runtime for the async/await macros in the
futures
crate -
heim-disk
Cross-platform disk information
-
real-async-trait
A proc macro that uses experimental features to work around type erasure for async traits
-
bottle
Actor model framework for Rust
-
again
wasm-compatible retry util for std library futures
-
futures-waitmap
future-based concurrent event waiting hashmap
-
sampr
A message passing framework using actors
-
implicit-await
Implicitly await calls returning Future impls
-
keclc-httpauth
HttpAuth support for Kayrx web
-
oneshot-broadcast
channel that broadcasts a value once without cloning it
-
streem
creating and consuming streams
-
async-ioutils
A collection of async utilities for I/O
-
bevy_async_system
ability to wait for game status asynchronously
-
actix-broker
Message broker for the Actix actor framework
-
cocoro
A more type-safe take on Rust stackless coroutines
-
async-graphql-viz
async-graphql for viz
-
simple-actor
Helper to write actor-based async code
-
serf
A decentralized solution for service discovery and orchestration that is lightweight, highly available, and fault tolerant
-
cloudflare-workers-kv-sdk-rs
Unofficial Cloudflare Workers KV SDK for Rust-Lang
-
cache-compute
implements request/async computation coalescing
-
zippyst
Resolve zippyshare.com download links
-
ttl_cache_with_purging
A time-to-live (TTL) cache implementation with optional background purging for expired entries
-
async-dup
Duplicate an async I/O handle
-
hyper_lua_actor
Binding of lua_actor & hyper
-
aster-proxy
A light, fast and powerful cache proxy written in Rust
-
awaitable-error
Awaitable type with input and output that can be stored in container
-
tokio-util_wasi
Additional utilities for working with Tokio
-
async-i3ipc
Bindings for i3 and async-std allowing async applications to communicate with i3 over it's IPC interface. Contains futures implementations and convenience functions for working with i3.
-
safina-net
Safe async network functions - ARCHIVED: Code moved to
safina
crate -
pipebuf_mio
PipeBuf support for
mio
byte-streams -
killswitch
used to broadcast a shutdown request
-
tower-amqp
Framework for building AMQP workers with tower
-
pipebuf_rustls
PipeBuf wrapper for Rustls
-
st7735-async-low
Low-level async library for 4-wire serial ST7735
-
strife
A lightweight library for the Discord API
-
mega_etl
A cloud-native ETL (Extract, Transform, Load) application framework based on the WasmEdge WebAssembly runtime for developers to filter, map, and transform data pipelines going into cloud databases
-
agreed-memstore
An in-memory implementation of the
agreed::RaftStorage
trait. Fork of async-raft’s memstore crate. -
reqwest-streams
HTTP body streaming support for reqwest: JSON/CSV/Protobuf and others
-
jarust_rt
A janus client SDK in Rust
-
mofo
Multiple Ongoing Futures Object - an abstraction for easily managing ongoing child tasks with futures
-
jelastic-rs
Rust wrapper for the Jelastic API
-
async-http-client-lite
Asynchronous http client
-
fil_actors_runtime_v10
System actors for the Filecoin protocol
-
veilid-async-tls
Asynchronous TLS/SSL streams using Rustls
-
async-weighted-semaphore
An async weighted semaphore
-
tokio-tls-gmssl
TLS/SSL streams for Tokio using native-tls giving an implementation of TLS for nonblocking I/O streams
-
desaturate
This package aims to makes it easier to maintain a single code base for both regular and async functions
-
akt
An actors library for Rust and Tokio designed to work with async / await message handlers out of the box
-
tower-sessions-surrealdb-store
SurrealDB session store. Not for direct use; see the
tower-sessions
crate for details. -
minicoro-sys
rust binding to minicoro
-
flynn-openai
OpenAI
-
dd-tracing-layer
Send your logs to Datadog
-
fibers_tasque
A
tasque
extension specialized forfibers
-
async-attributes
Experimental language-level polyfills for Async Rust
-
async-shell
Asynchronous process child wait
-
futures-stable-preview
futures which support internal references
-
basteh
Generic kv storage with replaceable backend
-
elfo-utils
Some utils for the elfo system
-
vertigo
Reactive Real-DOM library with SSR for Rust
-
bader-db
Key-value cache RESP server with support for key expirations
-
rados_hi
Opinionated high-level wrapper for librados (Ceph)
-
ctrlgen
Generate enums for message-passing services
-
sn_data_types
Safe Network Data Types
-
uringy
single-threaded concurrency runtime for Rust based on io_uring
-
tokio-fastcgi
FastCGI handler (responder, authorizer, filter) library for Tokio
-
async-subscription-map
Async bookkeeping datastructure for state subscriptions
-
folo
Runtime engine for Rust services
-
cargo-daku
Daku API cargo plugin
-
tower-buffer
Buffer requests before dispatching to a
Service
-
proxied
Asynchronous client connector for proxies
-
northstar-rcon-client
Asynchronous RCON client for the Northstar mod
-
signalwire
The unofficial SignalWire SDK for Rust
-
uller
Generate/Donwload your links
-
jsonrpc-rs
Futures base jsonrpc server/client framework
-
background-jobs-core
Core types for implementing an asynchronous jobs processor
-
async-compat
Compatibility adapter between tokio and futures
-
bb8-ruarango
bb8 connection pooling impmentation for the ArangoDB database
-
plumb
A functional, async pipeline framework
-
troupe
modelling Rust applications with actors
-
fourche
task queue named after a lion with forked tail (queue fourché), works with Redis
-
riker-patterns
A collection of common actor patterns for Riker
-
spmc-logger
A single-producer multi-consumer persistent logger
-
telers
An asynchronous framework for Telegram Bot API written in Rust
-
v_exchanges_adapters
Implementations of HTTP/HTTPS/WebSocket API methods for some crypto exchanges, using crypto-botters framework
-
tractor
Actor system modelled after Pony's actors
-
tokio-hglib
Tokio-based async client library for Mercurial command server
-
feature-extension-for-async-std
Feature extension for async-std
-
tokio-futures-respawn
function to respawn failed long running tasks
-
arti-bench
benchmarking utility for Arti
-
sfio-tokio-ffi
An oo-bindgen model for using Tokio in an FFI environment
-
tigerbeetle-unofficial-core
Safe low level callback-based async bindings to tigerbeetle client library
-
vru-cancel
Cancel tokio stream
-
tokio-udev
Non-blocking/Asynchronous Tokio support for udev device events
-
deli
ergonomic way to define data models that are seamlessly converted into IndexedDB object stores, utilizing derive macros
-
common-multipart-rfc7578
multipart/form-data (RFC7578)
-
bookkeeper-client
Async rust client for Apache BookKeeper
-
fibers_inotify
A futures friendly inotify wrapper for fibers crate
-
future-result
An ideomatic way of mapping a Result to a Future of Result
-
async-resource
Async resource pool
-
kvarn_async
Async utilities used in the Kvarn web server
-
noosphere-ipfs
An interface for an IPFS client
-
tokio-macros
Tokio's proc macros
-
async-openai-alt
OpenAI
-
attempt
do something over and over and over and over and
-
mobc-bolt
A bolt-client manager for the mobc connection pool
-
openssh-sftp-protocol-error
Data format used to communicate with openssh mux server
-
wasm-agnostic
users who want to write async runtime-agnostic crate for wasm target
-
wasmflow-traits
encapsulating the message packets sent across Wasmflow components
-
crossbus
A Platform-Less Runtime-Less Actor Computing Model
-
izihawa-common-multipart
multipart/form-data
-
tower-balance
Balance load across a set of uniform services
-
async-pidfd
Process file descriptors (pidfd) for Linux
-
rocketmq-broker
Unofficial Rust implementation of Apache RocketMQ
-
async-middleware
async monad(ish) middleware in Rust using tuples and async trait transforms
-
puppet
actor framework which uses no dynamic dispatch or boxing
-
deploy-common
Common components for the
deploy
andfabric
crates -
tower-sessions-sqlx-store-chrono
SQLx session stores for
tower-sessions
but usingchrono
instead oftime
-
elk-mq
A Message Queue implementation in rust, using Redis as a communication medium
-
linux-io-uring
The
io_uring
library for Rust -
tokio-takconnect
Asynchronous Playtak client
-
coerce-rt
Async actor runtime
-
yaaf
Actor Framework
-
remcached
Caching system designed for efficient storage and retrieval of entities from remote repositories (REST APIs, Database, ...etc)
-
dydx
dYdX v4 asynchronous client
-
smol-timeout2
A way to poll a future until it or a timer completes
-
stream-flatten-iters
Flattens a stream of iterators into one continuous stream
-
async-graphql-axum-wasi
async-graphql for axum
-
spotify-rs
wrapper for the Spotify API
-
libp2p-dns
DNS transport implementation for libp2p
-
tes3mp-plugin
Stubs for creating a TES3MP server plugin
-
etcd-rs
etcd client for rust
-
relock
Distributed async locking using Redis
-
luarmor
API wrapper for luarmor.net
-
noosphere-into
Transformations of Noosphere content into various target formats
-
tonic-middleware
Async middleware and interceptor for Tonic services
-
signald-rust
interface with Signald
-
async_dag
An async task scheduling utilitiy
-
rusher
Pusher compatible pubsub service
-
lunatic-messaging-api
Lunatic host functions for message sending
-
atm-async-utils
implementing and testing futures::Sink and futures::Stream related code
-
ero
Erlang-inspired framework for organizing async code in a fault-tolerant way
-
suspend-channel
Channel and stream implementations
-
shared_stream
easily cloneable streams
-
tokio-shield
Prevent futures from being aborted by wrapping them in tasks
-
supplicant
Bindings for wpa_supplicant
-
starpu-sys
Low-level bindings to the StarPU runtime
-
spawns-compat
Async runtime detections for thread context task spawner
-
booru-dl
A command line tool to download images and tags txt from booru
-
tokio-timerfd
timerfd support for tokio
-
serio
providing traits and utilities for typed IO using format agnostic serialization built on serde
-
associated-async-io
Async IO traits that use futures instead of poll
-
elfo-telemeter
Collects and exposes metrics of the elfo system
-
core-futures-tls
A libcore wrapper allowing async/await to be used from no_std crates
-
futures-stream-select-ext
futures::stream::select Ext
-
axum-router-plugin
Shared library-based plugins for Axum
-
deadpool-amqprs
Dead simple async pool for amqprs
-
hyper-futures
Compatibility layer for futures to use AsyncRead and AsyncWrite traits with hyper
-
crb-superagent
CRB | Composable Runtime Blocks | Agent Extensions
-
async-option
Essentially an asynchronous Async<Mutex<Option<T>>>
-
dndx-fork-tokio-tun
Asynchronous allocation of TUN/TAP devices using tokio
-
asyncio-utils
Support limit,skip on AsyncRead traits
-
greenthread-future
Convert closures to futures based on greenthread on bare-metal (no_std + no_alloc)
-
fred
An async client for Redis and Valkey
-
rseip-eip
encapsulation protocol for rseip
-
tokiactor
tokio based Actor framework
-
rtix
Actors with generators. Name up for grabs until I do something with it, or rust supports proper coroutines
-
edge-dhcp
Async +
no_std
+ no-alloc implementation of the DHCP protocol -
tokio-context
Contexts for cancelling asynchronous tasks using tokio
-
kad
A generic / futures based implementation of the Kademlia Distributed Hash Table (DHT)
-
async-acme
async ACME client for tls-alpn-01 challenge
-
ws-gonzale
Naive websocket server implemented using async / await
-
syndicate
Syndicated Actor model for Rust, including network communication and Dataspaces
-
derive-tokio-io
Derive AsyncRead and AsyncWrite
-
unix-udp-sock
async & sync UDP sockets supporting sendmsg/recvmsg and src IP manipulation
-
openssh-mux-client
openssh mux client
-
comet-eventbus
strong-typed sync and asynchronous eventbus
-
peace_webi
Web interface for the peace automation framework
-
waitfor
Retry a function until it succeeds, errors out, or a timeout/deadline is reached
-
agilulf_protocol
Agilulf Protocol serializer and deserializer
-
actix-server
General purpose TCP server built for the Actix ecosystem
-
futures-utils-lite
futures about utils in lite
-
one_for_one
supervize spawn'ed async tasks
-
rosey-actors
Actor framework
-
opentls
TLS connections with OpenSSL
-
tokio-compat-02
Tokio 0.2 compat utilities
-
peace_rt
Runtime logic for the peace automation library
-
htmxtools
A lightweight Rust crate for working with HTMX headers, specifically designed to integrate seamlessly with axum
-
svix
Svix webhooks API client and webhook verification library
-
mqtt-channel-client
MQTT client that communicates over Tokio channels
-
async-compression
Adaptors between compression crates and Rust's modern asynchronous IO types
-
compio-tls
TLS adaptor with compio
-
async-gitlib
Asynchronous library with libgit2 artifacts
-
futures-length-delimited-frame
Frame a stream of bytes based on a length prefix
-
volo-thrift
Thrift RPC framework implementation of volo
-
specta-serde
Serde support for Specta
-
vanilla_tokio_actor
Vanilla Tokio Actor
-
evermore
allowing you to run an fixed number of asynchronous task repeatedly until a shutdown signal is sent out
-
async_event_streams
Asynchronous Events Pub/Sub Library
-
tokio-task-manager
Allow an async Tokio application to gracefully shutdown, waiting for all tasks to finish
-
hooch-macro
Procedural macros for the hooch async runtime
-
busybody
Service Container and Dependency injector crate
-
kay_codegen
Code generation for implementing kay actors
-
mold2d
platformer game library in Rust
-
futures-stream-reader
Convert an [AsyncRead] into a [Stream] of byte chunks
-
futuresdr-pmt
Polymorphic Types for an Experimental Async SDR Runtime for Heterogeneous Architectures
-
surrealdb-async-graphql-axum
async-graphql for axum
-
eventually
using Event Sourcing in Rust applications
-
ntex-files
Static files support for ntex web
-
futures-test-sink
Test utilities for futures::sink
-
beul
It executes futures
-
chikatetsu
An(other) actor framework for Tokio
-
nats-handling
async NATS client library
-
async-throttle
Asynchronous Rate Limiting
-
stream-future
Implement an async iterator with return value
-
completeq-rs
An alternative to passing messages between asynchronous tasks
-
json-array-stream
Incrementally reads a JSON array through an async stream
-
async-cuda-core
Async CUDA streams and buffers for Rust
-
posixmq
An idiomatic library for using posix message queues, with optional mio integration
-
async-rustls-stream
An async tls stream library based on rustls and futures-io. Both for server/client.
-
takyon
single threaded async runtime
-
swimos_introspection
SwimOS Agent Introspection
-
holidayapi_rust
A HolidayAPI library for Rust
-
async-trait-ext
a procedural macro for async traits
-
zephyrus-macros
Procedural macros used by Zephyrus
-
fil_actors_runtime_v9
System actors for the Filecoin protocol
-
async-graphql-value
GraphQL value for async-graphql
-
minimal-executor
A minimal executor for asynchronous tasks based on the futures-rs library
-
threaded_logger
An asynchronous logger wrapper
-
docker_engine_api
way to interact with the Docker Engine API
-
num_stream
that provides a Stream that yields incrementing numbers at a specified interval
-
sendblue
that provides an API client for interacting with the SendBlue REST API, enabling businesses to integrate iMessage and SMS services into their applications
-
asteroid-mq-model
Basic models for asteroid-mq
-
retry-if-macro
A tokio-compatible attribute-macro for decorating methods and functions with an exponential backoff
-
txrx
take on the C++ unified executors proposal
-
aspartam
Minimalistic actor framework based on tokio, inspired by actix
-
libevent
Rust bindings to the libevent async I/O framework
-
its_ok_to_be_block_on
A minimal implementation of block_on, to execute futures in a syncronous context
-
fs4
No libc, pure Rust cross-platform file locks. Original fs2, now supports async and replace libc by rustix.
-
nature
development support platform, it separates data definition from code, so it decouple the data from business system
-
async_main
Runtime-agnostic async main proc macro
-
rust-gpt
interaction with the Completion/Chat OpenAI API
-
ockam_transport_websocket
WebSocket Transport for the Ockam Routing Protocol
-
jstream-ext
adds some extra extensions to futures Stream traits
-
puddle
object pool implementation that uses asynchronous synchronization primitives only
-
chtsh
Rust CLI for interacting with https://cht.sh
-
async-diesel
Integrate Diesel into async-std cleanly and efficiently
-
genawaiter-macro
Convenience macros for generators (genawaiter)
-
f1-api
F1 API is a client library for the telemetry API of the F1 video games by Codemasters. It uses asynchronous networking to decode the incoming UDP packets, and turns them into strongly typed Rust structs.
-
egui_task_manager
Manage asynchronous easily
-
async-global-executor-trait
executor-trait implementation for async-global-executor
-
mwmr
A generic optimistic transaction manger, which is ACID, concurrent with SSI (Serializable Snapshot Isolation)
-
remoc
🦑 Remote multiplexed objects, channels, observable collections and RPC making remote interactions seamless. Provides multiple remote channels and RPC over TCP, TLS or any other transport.
-
rdbc-rs
Futures base Rust DataBase Connectivity (RDBC) library
-
compio-io
IO traits for completion based async IO
-
async-core
A standard for async runtimes
-
tower-async-bridge
Bridges a
tower-async
Service
to be used within atower
(classic) environment, and also the other way around -
rotor
The mio-based framework for doing I/O in simple and composable way
-
aldrin
Message bus for service-oriented RPC and interprocess communication
-
bytes-stream
functions to work with stream of bytes
-
async-graphql
A GraphQL server library implemented in Rust
-
rxqlite-sqlx-common
A distributed sqlite database built upon
openraft
,sqlx
andsqlite
-
nr-tracing-layer
Send your logs to New Relic
-
vmc
Virtual Motion Capture protocol for virtual avatar tracking
-
aector
Dynamic implementation of the actor model with a smart built-in testing framework
-
cynthia
A high performance asynchronous programming runtime for Rust
-
futurify
Convert your sync functions into non-blocking thread futures
-
awaitable-bool
A Tokio-powered awaitable bool (analogous to a flag and highly inspired by Python’s
asyncio.Event
, but can be waited for to become ‘false’ too) -
async-stream-packed
Asynchronous stream packed
-
alzheimer
Async implementation of brainfuck interpreter
-
rabble
creating location transparent actor based systems
-
bevy_impulse
Reactive programming and workflow execution for bevy
-
wasmcloud-interface-sleepy
Interface for interacting with the sleepy capability provider
-
indexed-db
Bindings to IndexedDB that default the transactions to aborting and can work multi-threaded
-
barrage
An async broadcast channel
-
linux-io-uring-sys
The
io_uring
bindings for Rust -
rasi-ext
includes extend features or experimental features that are useful for asynchronous programming
-
clia-ntex-files
Static files support for ntex web
-
peace_resources
Runtime resources for the peace automation framework
-
async-reactor-trait
reactor-trait implementation for async-io
-
pipebuf_websocket
PipeBuf support for websockets
-
tokio-dbus
Pure Rust D-Bus implementation for Tokio
-
casus
containing a handful of event-based async primitives
-
tasky
fluent async task experiments
-
zusammen
Download files in parallel
-
jarust_plugins
A janus client SDK in Rust
-
photonio
A runtime for asynchronous applications
-
tower-sessions-moka-store
Moka session store for
tower-sessions
-
libp2p-swarm
The libp2p swarm
-
waitlist
Keep track of an ordered list of Wakers to wake
-
tokio-task-pool
Task pool for Tokio Runtime
-
waker-set
waker set
-
futures-to-stream
Turn heterogeneous Futures of same associated Output type to a stream
-
reqwest-eventsource
Helper to build an Eventsource using reqwest
-
async-tick
tick clock
-
stream-reduce
Fold a stream without an initial value
-
tower-timeout
Apply a timeout to requests, ensuring completion within a fixed time duration
-
actix-ws-ng
WebSockets for Actix Web, without actors
-
mysql_async_uu
Tokio based asynchronous MySql client library
-
tokio-iocp
IOCP support for the Tokio asynchronous runtime
-
compio-dispatcher
Multithreading dispatcher for compio
-
tasktrace
Logical 'backtraces' of async tasks
-
async-priority-queue
An async-aware priority queue
-
noosphere-storage
Pluggable backing storage for the Rust Noosphere implementation
-
fastcgi-client
Fastcgi client implemented for Rust
-
ockam_transport_uds
Unix Domain Socket (UDS) Transport for the Ockam Routing Protocol
-
pyo3-anyio
PyO3 utility bindings for Anyio's event loop
-
specta-jsdoc
Export your Rust types to JSDoc
-
improv
Actor microframework
-
aligne
A small crate using tokio to synchronize asynchronous request/response with Ids
-
misskey-util
High-level API for the misskey-rs library
-
memstore
An in-memory implementation of the
async-raft::RaftStorage
trait -
tower-make
Trait aliases for Services that produce specific types of Responses
-
file-descriptors
Wrapper around the common kinds of (mostly Linux) file descriptors, including sockets, pipes, FIFOs, terminals, serial ports, character devices, epoll, POSIX message queues, timerfd…
-
felixs-tower-lsp
Language Server Protocol implementation based on Tower
-
lazy-queue
Futures-driven lazy queue processing
-
delay
A collection of trait and classes to make your thread wait (and timeout)
-
tls-async
TLS support for AsyncRead/AsyncWrite using native-tls
-
compio-signal
Signal handling for compio
-
aral-runtime-async-std
Aral Runtime for async-std
-
aktrs
An actor model framework for Rust
-
async-macros
Macros for async-std
-
trovo
A trovo.live api & chat client written in and for rust
-
thetvdb
API async client
-
form-data
AsyncRead/AsyncWrite/Stream
multipart/form-data
-
tokio-beanstalkd
Asynchronous client library for interacting with Beanstalkd work queue
-
tabs
A collection of asynchronous task abstractions, based on tokio
-
tower-sessions-libsql-store
A small library for using tower-sessions with libsql
-
waker-waiter
async runtimes interoperate with arbitrary futures
-
monolake
High Performance Proxy base on Monoio
-
streaming-platform
Data streaming platform and message broker with concurrent data transfer capabilities
-
async-component
Zero overhead reactive programming
-
winit-runtime
Async winit runtime
-
mysql_async_wasi
Tokio based asynchronous MySql client library
-
generic-api-client
A client for HTTP/HTTPS/WebSocket APIs
-
seal_rs
Set of classic asynchronous primitives (Actors, Executors, Futures / Promises)
-
kyansel
Cancellable future. Provide a future as argument and the current future will cancel if the provided future resolves first
-
b_stb
that efficiently converts Hyper response bodies and async streams into strings or bytes
-
stry-evermore
allowing you to run an fixed number of asynchronous task repeatedly until a shutdown signal is sent out
-
sendgrid-async
An async-std based client for sending emails with SendGrid
-
await_macros
Macros that expand to
(expr).await
-
heim-net
Cross-platform network information
-
windows-async
async executor for windows application using windows crate
-
elfo-dumper
Dumps messages of the elfo system on disk
-
socketioxide-parser-common
Common parser for the socketioxide protocol
-
lspower
A lightweight framework for implementing LSP servers
-
taskwait
Runtime agnostic way to wait for a group of async tasks
-
async-zmq-types
Types and traits to create a generic interface over asynchronous zmq implementations
-
crb-routine
CRB | Composable Runtime Blocks | Routine
-
mobc-lapin
RabbitMQ support for the async mobc connection pool
-
async-thread
Futures version of std::thread
-
relay
A lightweight oneshot Future channel
-
future-bool
A bool one can await the changes
-
async-imap-lite
Asynchronous imap
-
actix-storage-dashmap
actix-storage based on dashmap
-
carrot-cake
An a-peeling pub/sub framework
-
agner
An actor toolkit inspired by Erlang/OTP
-
mio-timerfd
mio support for linux's timerfd
-
lucia-apis
A set of API collections based on the lucia framework
-
logimesh
RPC Microservice 2.0 framework
-
task_yield
Executor-independent task yielding
-
embassy-futures
no-std, no-alloc utilities for working with futures
-
switchyard
Real-time compute focused async executor
-
pin-cursor
!Unpin I/O backend for async-std
-
cf-pty-process-alpha
the tab multiplexer fork of tokio-pty-process. Interact with a child process through a pseudo-TTY, asynchronously using Tokio
-
futures-enum
#[derive(Future, Stream, Sink, AsyncRead, AsyncWrite, AsyncSeek, AsyncBufRead)] for enums
-
switch-resume
Delimited async continuations
-
multipart-rs
zero-allocation, streaming, async multipart reader & writer for Rust
-
workflow-async-trait
Type erasure for async trait methods (customized, see README.md notes)
-
deadpool-fantoccini
Dead simple async session pool for fantoccini
-
elfo-logger
Logs events of the elfo system
-
what-the-async
runtime
-
wtr-watcher
Filesystem watcher. Works anywhere. Simple, efficient and friendly.
-
volo
high-performance and strong-extensibility Rust RPC framework that helps developers build microservices
-
chokepoint
Generic stream transformer to simulate traffic / network congestion
-
peace_rt_model
Runtime data types for the peace automation framework
-
merge-io
Merge two separate
AsyncRead
andAsyncWrite
objects into a single I/O stream -
reqwest-retry-after
Retry-After header support for reqwest
-
netbeam
a pure-rust asynchronous network synchronization crate (using tokio) that recreates familiar asynchronous paradigms but in a network context
-
toy-rpc
An async RPC that mimics golang net/rpc's usage and supports both async-std and tokio
-
aredis
Redis client implemented in Rust
-
agency
A small async actor framework
-
airlock
no_std async communication
-
param
Param-style trait
-
ffi_rpc
Use FFI with RPC
-
ws_stream_wasm
A convenience library for using websockets in WASM
-
motore-macros
Motore's proc macros
-
holly
A simplistic actor model library using futures
-
irc
usable, async IRC for Rust
-
async-mesos
An asynchronous client for Mesos HTTP scheduler API
-
tacacs-plus
An asynchronous, runtime-independent RFC8907 TACACS+ client
-
mfio-rt
mfio based async runtime
-
actix-codec
Codec utilities for working with framed protocols
-
mezzenger-channel
mezzenger transport over futures channels
-
relaxed_channel
Wrapper around async-channel, more performant on heavy pipelines
-
eventual
Future & Stream abstraction
-
causality
Event Driven Architecture Traits
-
backstage
A framework for building data-driven distributed systems
-
futuresdr-remote
Remote interaction library for FutureSDR
-
throttled-reader
An io::Read proxy that limits calls to read()
-
scoped_spawn
Full structured concurrency for asynchronous programming
-
tokio-io-compat
Compatibility wrapper around std io traits that implements tokio io traits
-
eventbuzz_core
The core submodule of eventbuzz project
-
mio-misc
Miscellaneous components for use with Mio
-
heim-runtime
Runtime shims for heim crate
-
koibumi-socks
A minimal SOCKS5 client library
-
upc
USB packet channel (UPC): provides a reliable, packet-based transport over USB
-
gloo-timers
Convenience crate for working with JavaScript timers
-
async-ready
Async readiness traits
-
async-graphql-rocket
async-graphql for Rocket.rs
-
async-stdin
Asynchronously read from stdin
-
build_async
Rust Macros to Unify Synchronous and Asynchronous Codebases
-
jackrabbit
Real-time Message Queue
-
scambio
Safe and efficient value exchanges between endpoint pairs
-
future_pubsub
A tokio based publish-subscibe channel
-
axum-sessions
🥠 Cookie-based sessions for Axum via async-session
-
bounded_join_set
A Concurrency-Limited JoinSet for Tokio
-
socksv5_future
Socks v5 futures for Server and Client
-
gwyh
sweet gossip library
-
absinthe
Are you an Actor & Async junkie? Then your app needs some Absinthe!
-
swiftide-core
Blazing fast, streaming pipeline library for AI applications
-
tokio-tasker
Lets you stop and join groups of Tokio tasks
-
tower-retry
Retry failed requests
-
uring-fs
Truly asynchronous file operations using io-uring. Supports any async runtime. Linux only.
-
framed_aio
allows performing async io operations in a framed manner
-
repeating_future
[RepeatingFuture] is a [Future] that can call an async function of an object over and over again
-
pulz-executor
Abstractions of some async runtimes
-
tower-sessions-file-based-store
File-based session store for
tower-sessions
-
async_buf_reader_utils
Adds additional functionality to the async-std crate for BufReader
-
vesper-macros
Procedural macros used by Zephyrus
-
async-events-emitter
providing an implementation of an event handling system
-
plctag
wrapper of libplctag, with rust style APIs and useful extensions
-
tower
modular and reusable components for building robust clients and servers
-
agner-test-actor
An actor toolkit inspired by Erlang/OTP (test-actor)
-
libp2p-webtransport-websys
WebTransport for libp2p under WASM environment
-
task-stream
a global task executor, run in
no_std
-
zonyitoo/coio
Coroutine scheduler with non-blocking I/O support
-
geese_executor
Asynchronous executor with Geese event system integration
-
turbocharger
Autogenerated async RPC bindings that instantly connect a JS frontend to a Rust backend service via WebSockets and WASM
-
stream_multiplexer
Combines many streams into a few
-
stream-map-any
Allows merging async Streams of different output type
-
async-tun
Asynchronous allocation of TUN/TAP devices using async-std
-
tokio-utils
Tools for asynchronous programming in Tokio applications
-
spawns-core
Async runtime agnostic thread context task spawner for Rust
-
RobotS
Actor framework
-
rillrate-system
RillRate agent for system monitoring
-
http-lib
High-level, asynchronous API for ureq, a safe HTTP client
-
async-await
Just some macros to emulate the Async and Await :)
-
ratchet_ext
WebSocket extensions for Ratchet
-
actor
Actors traits
-
celery-rs-core
Core utilities for a celery client and worker in rust
-
tower-async
Tower Async is a library of modular and reusable components for building robust clients and servers. An "Async Trait" fork from the original Tower Library.
-
genawaiter2-proc-macro
procedural macro for generators (genawaiter2)
-
clia-ntex-files-mod
A mod to ntex-files, supporting '.' leading
-
websocket_toolkit
A WebSocket toolkit for Rust, enabling efficient real-time communication with flexible reconnection and message handling capabilities
-
agner-reg
An actor toolkit inspired by Erlang/OTP (reg)
-
skipdb-core
The core for
skipdb
andasync-skipdb
crates -
ruchei-callback
Callback traits for ruchei
-
core-futures-stateless
Workaround for no_std async-await that doesn't store task contexts
-
arta-async-std
Async abstractions implementation for async-std
-
bongonet-openssl
OpenSSL async APIs for Bongonet
-
asteroid-mq-sdk
Rust SDK for asteroid-mq
-
flo_binding
Declarative binding library for Rust
-
rupnp
An asynchronous library for finding UPnP control points, performing actions on them and reading their service descriptions
-
o5m-stream
streaming async o5m decoder
-
sigfinn
Lifecycle manager for spawning tasks
-
async_io_crypto
handling AsyncRead with ciphering / deciphering
-
nodecraft
Crafting seamless node operations for distributed systems, which provides foundational traits for node identification and address resolution
-
tangle
Future implementation for Rust
-
jarust_interface
A janus client SDK in Rust
-
tokio-non-async
Helpers for dealing with tokio channels in non-async code
-
madsim-tonic
The
tonic
simulator on madsim -
mini-telnet
Asynchronous minimal telnet library
-
nonblocking
stdin crate for Rust
-
flv-future-aio
I/O futures for Fluvio project
-
cyper
HTTP client library based on compio and hyper
-
ruchei-extra
Stream/Sink wrapper with extra data, as used by ruchei
-
manual-executor
Async executor with manual waking
-
async-ucx
Asynchronous Rust bindings to UCX
-
task-executor
A task executor
-
tonic-health
Health Checking module of
tonic
gRPC implementation -
poem-grpc
GRPC support for Poem
-
async-utils
nothing to see here yet :)
-
edge-nal-std
A STD implementation of edge-nal based on
async-io
-
futures-macro-await
Definition of the
await!
macro for thefutures
crate -
drop-awaiter
that allows you to asynchronously wait for something to be dropped
-
tokio-channel
Channels for asynchronous communication using Tokio
-
futuredsp
A signal processing library for SDR and real-time DSP
-
redeez
queueing system for Redis
-
aio_event
A tokio event like asyncio event in python
-
stage
An ergonomic, composable Actor Model, designed for painless concurrency
-
mio-byte-fifo
Concurrent non-blocking byte SPSC FIFO buffer intended for use in Mio poll
-
uid-mux
Async multiplexing library with user provided stream ids
-
ntex-rt
ntex runtime
-
aldrin-gen
Aldrin code generator
-
aiur
Single threaded async executor with structured concurrency
-
nervemq
Portable, SQS-compatible message queue backed by SQLite
-
tor-events
A typed event broadcasting framework for Arti
-
fil_actors_runtime_v8
System actors for the Filecoin protocol
-
dmds-tokio-fs
Dmds I/O handler interacts with the filesystem using Tokio
-
tokio-dbus-macros
Pure Rust D-Bus implementation for Tokio
-
compio-process
Processes for compio
-
async-executor-trait
executor-trait implementation for async-std
-
shutdown-async
Asynchronous Shutdown
-
rseip-core
core module for rseip
-
fizyr-rpc
Native Rust implementation of the Fizyr RPC protocol
-
tower-service
Trait representing an asynchronous, request / response based, client or server
-
tower-async-http
Tower Async middleware and utilities for HTTP clients and servers. An "Async Trait" fork from the original Tower Library
-
smartpoll
A 'Task' abstraction that simplifies polling futures
-
tokio-eventfd
Linux eventfd for tokio
-
agner-init-ack
An actor toolkit inspired by Erlang/OTP (init-ack)
-
async-std-test
Alternate implementation of the #[async_std::test] macro
-
gain-lep
Support for exposing Gain APIs via Lep
-
tokio-buf
Asynchronous stream of byte buffers
-
awaken
Coalescing cross-thread wakers for mio and io_uring
-
tokio-into-sink
convert a tokio::io::AsyncWrite into a futures::Sink for bytes
-
name_locker
interface for asynchronous name lockers, that can run an async task with lock on a given name
-
socketioxide-parser-msgpack
Msgpack parser for the socketioxide protocol
-
async-bincode
Asynchronous access to a bincode-encoded item stream
-
nephele
A high performance asynchronous programming runtime for Rust
-
axum-messages
🛎️ One-time notification messages for Axum
-
specta-util
High-level utilities for working with Specta
-
bp3d-net
Network utilities
-
liburing
Rust liburing#24bd087 raw bindings with basic tests
-
async-transport
Asynchronous transports with ECN information
-
jarust_transport
A janus client SDK in Rust
-
netsim
Run tests in network-isolated threads. Intercept and meddle with their packets.
-
ws-lite
Naive websocket server implemented using async / await
-
twitchchat
interface to the irc-side of twitch's chat system
-
peace_rt_model_native
Runtime data types for the peace automation framework
-
light-magic
A lightweight, fast and easy-to-use implementation of a optionally encrypted/persistent in-memory database
-
tokio01-test
Testing utilities for Tokio and futures-based code
-
async-ioutil
A collection of Rust asynchronous I/O utilities
-
cqrs-core
Core types and traits for cqrs
-
futures-macro-await-preview
Definition of the
await!
macro for thefutures
crate -
tower-sessions-deadpool-sqlite-store
deadpool-sqlite session store for
tower-sessions
-
psbus
Generic Publish / Subscribe model for application messaging
-
feature-extension-for-wasm-bindgen-futures
Feature extension for wasm-bindgen-futures
-
thespis_impl
Reference implementation for the thespis actor model
-
nb-executor
Single-future, #![no_std] executor based on event bitmasks
-
tower-load-shed
Immediately reject requests if the inner service is not ready. This is also known as load-shedding.
-
nb-sync
Non-blocking synchronization structures for bare-metal environments
-
mpool
A generic connection pool
-
d3
A framework for server development
-
tokio-periodic
Cross-platform, mostly-0-cost asynchronous periodic timers
-
ant-libp2p-swarm
The libp2p swarm
-
hydro
cooperative green tasks
-
async_channel_io
AsyncRead
andAsyncWrite
implementations forasync_channel
-
uasync
fast, safe, async executor
-
pingora-openssl
OpenSSL async APIs for Pingora
-
tokio-blocking
A thin wrapper to provide a simple interface to insert blocking operations between non-blocking operations in the context of futures
-
wasm_main_executor
Run futures from web workers on the main browser thread
-
aurora-streams
managing publish-subscribe channels using Tokio message passing channels
-
fieldset
Struct to enum derivation
-
libp2p-relay
Communications relaying for libp2p
-
prefect
An embeddable task queue based on SQLite (renamed to effectum)
-
dialectic-tokio-mpsc
A backend for the Dialectic crate using Tokio's MPSC channels
-
somen
An asynchronous parser combinator
-
misanthropic
An async, ergonomic, client for Anthropic's Messages API
-
crb-morph
CRB | Composable Runtime Blocks | Morph
-
ratchet_fixture
Ratchet fixture
-
hop
Rust client library for the Api
-
diath
light-weight library for communication between tokio async tasks
-
nostd_async
An asyncronous runtime for a single-threaded no_std environment
-
rspc-tauri
Tauri adapter for rspc
-
fmmap
A flexible and convenient high-level mmap for zero-copy file I/O
-
libp2p-floodsub
Floodsub protocol for libp2p
-
peace_value_traits
Trait bounds for value types for the Peace framework
-
constellation-internal
Common components for the
constellation
framework -
arta
Async runtime abstractions library
-
ruyi
An event-driven framework for non-blocking, asynchronous I/O in Rust
-
completion-io
Core traits and types for asynchronous completion-based I/O
-
async-graphql-warp
async-graphql for warp
-
task_scheduler
easilty schedule an FnOnce to run in the future
-
futures-executor-preview
Executors for asynchronous tasks based on the futures-rs library
-
async-watch
Async watch channel
-
monoio-macros
Monoio proc macros
-
async-dashscope
client for DashScope API
-
actix-web-async-await
preview of Actix with async/await support
-
swiftide-macros
Blazing fast, streaming pipeline library for AI applications
-
bevy_flurx
Allows you to write sequential description of processes involving delays, user input, and other waits
-
mercury
The official Rust client for the Mercury Parser
-
actm
Tiny async actors framework for rust
-
elfo-pinger
Pings groups of the elfo system
-
openssh-sftp-protocol
Data format used to communicate with openssh mux server
-
tokio_safe_block_on
ability to execute async code from a sync context, without blocking a tokio core thread or busy looping the cpu
-
tokio-fd
Non-blocking Read and Write a Linux File Descriptor
-
compio-macros
Proc macro of compio
-
prodash
A dashboard for visualizing progress of asynchronous and possibly blocking tasks
-
catalyzer-utils
development easier
-
tower-worker
Tower layers focused on wrapping services with asynchronous worker tasks that may also make requests to the wrapped service
-
mirai
A Futures layer over Mio
-
elfo-network
Distributed actors for elfo
-
stream-body
An HttpBody implementation with efficient streaming support for the Rust HTTP library hyper
-
async-mongodb-session
An async-session implementation for MongoDB
-
asynchronous
Promises Q style , async and event loops
-
yaar
asynchronous runtime optimized around configuration and no_std
-
ant-libp2p-webtransport-websys
WebTransport for libp2p under WASM environment
-
mai
A higher-level mio interface
-
archflow
Create a streamable Zip archive
-
async-watch2
Async watch channel
-
crb-runtime
CRB | Composable Runtime Blocks | Runtime
-
springtime
Dependency injection based application bootstrapping and execution crate
-
tonic-web
grpc-web protocol translation for tonic services
-
async-timer-rs
Hashed timer wheel implementation compatible with asynchronous tasks, support async_std/tokio and other futures base framework
-
ara
Async random access I/O traits
-
axum-serveplus
High level server designed to be used with axum framework
-
tower-http
Tower middleware and utilities for HTTP clients and servers
-
mlg
An asynchronous Log for Rust
-
compio-log
Log of compio
-
smol-executor-trait
executor-trait implementation for smol
-
rustun
implementing STUN server and client asynchronously
-
dialectic-null
A no-op backend for the Dialectic crate, intended for benchmarking and testing
-
rust-freely
An asynchronous wrapper for the WriteFreely/Write.as API
-
safe-async-scoped
A minimal, safe library for scoped async tasks
-
actix-service
Service trait and combinators for representing asynchronous request/response operations
-
task_scope
asynchronous runtime extension for supporting Structured Concurrency with task spawning
-
pingora
A framework to build fast, reliable and programmable networked systems at Internet scale
-
shuller
Lib to get links to images for your favourite tags on rule34 and any
-
tokio-dbus-xml
Pure Rust D-Bus implementation for Tokio
-
wombo
managing event loop threads
-
actix-files
Static file serving for Actix Web
-
actix-tls
TLS acceptor and connector services for Actix ecosystem
-
ntex-io
encoding and decoding frames
-
v_rusty_tarantool
Tarantul async client based on tokio framework
-
openssh-sftp-client-lowlevel
Lowlevel utilities to communicate with openssh sftp server
-
armature
An event-driven stateful actor framework for Rust
-
pollster-macro
Proc-macro crate for pollster
-
gloo-events
Convenience crate for working with DOM event listeners
-
diny
An asynchronous, alloc-free serialization framework
-
fil_actors_runtime_v11
System actors for the Filecoin protocol
-
bevy_async_task
Ergonomic abstractions to async programming in Bevy
-
async-spawner
executor independent task spawner
-
async-graphql-parser
GraphQL query parser for async-graphql
-
async-graphql-poem
async-graphql for poem
-
juggle
Async task switching for cooperative multitasking in single thread environments with no_std support
-
futures-mpsc
A futures aware, bounded, MPSC channel with back pressure support
-
vkteams-bot
VK Teams Bot API client
-
memberlist
A highly customable, adaptable, async runtime agnostic Gossip protocol which helps manage cluster membership and member failure detection
-
libp2p-uds
Unix domain sockets transport for libp2p
-
nostr-bot
Nostr bot library
-
extern_executor
Async executor which delegates futures polling to external event-loop
-
peace_item_sh_cmd
Manages running a shell command for the peace framework
-
libp2p-stream
Generic stream protocols for libp2p
-
sendfile
wrapper around the sendfile(2) system call
-
variable-len-reader
reading/writing variable length data. Support AsyncRead/AsyncWrite in tokio.
-
madsim-etcd-client
The etcd simulator on madsim
-
see-you-later
Delay and schedule async task
-
madsim-tonic-build
Codegen module of
madsim-tonic
simulation implementation -
uring
Pure Rust library for io_uring
-
forkable
Fork-able iterators and asynchronous streams
-
libp2p-core
Core traits and structs of libp2p
-
futures-glib
Spawn futures on the glib event loop
-
digtask
Dig is a YAML-defined, OS-level task orchestrator. It can 'dig into' a specifed task, or 'dig out' a desired output file
-
one-file-raft
Raft consensus in 300 LOC
-
misskey-core
Core traits and types in misskey-rs
-
verypoll
Very polling library
-
rh2
An HTTP/2 client and server
-
folo_proc_macros
Internal dependency of the 'folo' crate - do not reference directly
-
libp2p-dcutr
Direct connection upgrade through relay
-
photonio-uring
A PhotonIO implementation based on io_uring
-
smol-axum
Integrations between
smol
andaxum
-
futuresdr-frontend
Web Frontend for an Experimental Async SDR Runtime for Heterogeneous Architectures
-
multitask
An executor for running async tasks
-
batch
Distributed task queue library based on RabbitMQ
-
handy_io
A handy pattern and futures based asynchronous I/O library
-
just-watch
Async watch channel
-
async-backtrace
Efficient, logical 'backtraces' of async tasks
-
simple-async
Very simple async runtime for Rust
-
logged-stream
Logging of all read/write operations, errors and drop of underlying IO object
-
openraft-macros
Advanced Raft consensus
-
emitter-rs
📢 Emitter RS is a lightweight EventEmitter implementation for Rust and Wasm
-
embassy-executor
async/await executor designed for embedded usage
-
socketioxide-redis
Redis adapter for the socket.io protocol
-
openssh-sftp-client
Highlevel API used to communicate with openssh sftp server
-
tarpc-lib
An RPC framework for Rust with a focus on ease of use
-
nb-connect
Non-blocking TCP or Unix connect
-
tinyio
A tiny Rust concurrency runtime library
-
mioqu
queuing and processing background tasks
-
crb-core
CRB | Composable Runtime Blocks | Core
-
holiday_event_api
The Official Holiday and Event API for Rust
-
actix-postgres
PostgreSQL integration for Actix framework
-
wakerpool
lightweight object pool for lists of Wakers
-
erkpht-tower
Tower is a library of modular and reusable components for building robust clients and servers
-
ntex-service
ntex service
-
openraft-sledstore
A sled based implementation of the
openraft::RaftStorage
trait -
async-graphql-axum
async-graphql for axum
-
h2
An HTTP/2 client and server
-
netapp
A toolkit library for distributed software
-
peace_item_spec_file_download
Manages downloading a file for the peace framework
-
rxqlite-tests-common
A distributed sqlite database built upon
openraft
,sqlx
andsqlite
-
peace_item_tar_x
Manages extracting a tar file for the peace framework
-
task-compat
compat futures 0.1 and futures 0.3 tasks
-
direct-executor
An executor that directly executes futures, suitable for embedded environments