-
mio
Lightweight non-blocking I/O
-
futures
streams featuring zero allocations, composability, and iterator-like interfaces
-
tower
modular and reusable components for building robust clients and servers
-
tokio
An event-driven, non-blocking I/O platform for writing asynchronous I/O backed applications
-
tonic
A gRPC over HTTP/2 implementation focused on high performance, interoperability, and flexibility
-
tokio-rustls
Asynchronous TLS/SSL streams for Tokio using Rustls
-
futures-lite
Futures, streams, and async I/O combinators
-
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
-
h2
An HTTP/2 client and server
-
async-io
Async I/O and timers
-
rdkafka
Rust wrapper for librdkafka
-
bb8
Full-featured async (tokio-based) connection pool (like r2d2)
-
pollster
Synchronously block the thread until a future completes
-
futures-concurrency
Structured concurrency operations for async Rust
-
blocking
A thread pool for isolating blocking I/O in async programs
-
scc
High-performance containers and utilities for concurrent and asynchronous programming
-
async-broadcast
Async broadcast channels
-
tokio-serial
A serial port implementation for tokio
-
backon
Make retry like a built-in feature provided by Rust
-
async-openai
OpenAI
-
tower-sessions
🥠 Sessions as a
tower
andaxum
middleware -
io-uring
The low-level
io_uring
userspace interface for 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
-
keycloak
Admin REST API
-
want
Detect when another Future wants a result
-
ractor
A actor framework for Rust
-
crdts
Practical, serializable, thoroughly tested CRDTs
-
amqprs
AMQP 0-9-1 client implementation for RabbitMQ
-
tracing-actix-web
Structured logging middleware for actix-web
-
actix-codec
Codec utilities for working with framed protocols
-
apalis
extensible multithreaded background job processing for Rust
-
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.
-
ipc-channel
A multiprocess drop-in replacement for Rust channels
-
futures-locks
Futures-aware lock primitives
-
monoio
A thread per core runtime based on iouring
-
diatomic-waker
An async, lock-free synchronization primitive for task wakeup
-
containerd-shim
containerd shim extension
-
openraft
Advanced Raft consensus
-
futures-signals
Zero cost FRP signals using the futures crate
-
tokio-graceful
util for graceful shutdown of tokio applications
-
asynchronous-codec
encoding and decoding frames using
async/await
-
gix-actor
A way to identify git actors
-
tokio-metrics
Runtime and task level metrics for Tokio applications
-
failsafe
A circuit breaker implementation
-
tokio-graceful-shutdown
perform a graceful shutdown on a Tokio based service
-
futures-buffered
future concurrency primitives with emphasis on performance and low memory usage
-
async-task
Task abstraction for building executors
-
async-global-executor
A global executor built on top of async-executor and async-io
-
tokio-retry2
Extensible, asynchronous retry behaviours for futures/tokio
-
tachyonix
A very fast asynchronous, multi-producer, single-consumer bounded channel
-
unicycle
A scheduler for driving a large number of futures
-
stream-download
streaming content to a local cache
-
exponential-backoff
An exponential backoff generator with jitter
-
tokio-socks
Asynchronous SOCKS proxy support for Rust
-
capnp-futures
async serialization for Cap'n Proto messages
-
pi-async-rt
Based on future (MVP), a universal asynchronous runtime and tool used to provide a foundation for the outside world
-
rxrust
Reactive Extensions
-
axum-streams
HTTP body streaming support for Axum: json/csv/protobuf/arrow/txt
-
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
-
tor-rtcompat
Compatibility layer for asynchronous runtimes, used by Tor
-
tarpc
An RPC framework for Rust with a focus on ease of use
-
iroh-quinn-proto
State machine for the QUIC transport protocol
-
eyeball
Add observability to your Rust types!
-
swiftide
Fast, streaming indexing, query, and agentic LLM applications in Rust
-
polling
Portable interface to epoll, kqueue, event ports, and IOCP
-
async-shutdown
one-stop solution for async graceful shutdown
-
eventsource-stream
A basic building block for building an Eventsource from a Stream of bytes
-
madsim
Deterministic Simulator for distributed systems
-
actix
Actor framework for Rust
-
r2g_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
-
async-walkdir
Asynchronous directory traversal for Rust
-
twilight-standby
filter wait for filtered incoming events for the Twilight ecosystem
-
future-queue
Adapters to manage a queue of futures, where each future can have a different weight
-
tokio-pipe
Asynchronous pipe(2) library using tokio
-
tokio-tun
Asynchronous allocation of TUN/TAP devices using tokio
-
service-async
A Service like tower in async style
-
tokio-retry
Extensible, asynchronous retry behaviours for futures/tokio
-
rustix-uring
The low-level
io_uring
userspace interface for Rust -
esrs
A Prima.it-opinionated library to achieve cqrs/es
-
kafka
Rust client for Apache Kafka
-
ws_stream_tungstenite
Provide AsyncRead/AsyncWrite over Tungstenite WebSockets
-
igd-next
Internet Gateway Protocol client
-
motore
modular and reusable components for building robust clients and servers. Motore is greatly inspired by Tower.
-
kdbplus
Dual q/kdb+ interface for API to build a shared library and an IPC client
-
tokio-io-timeout
Tokio wrappers which apply timeouts to IO operations
-
tauri-specta
Completely typesafe Tauri commands
-
tmq
ZeroMQ bindings for Tokio
-
tokio-io-utility
Some helper functions for tokio::io
-
mio-serial
A serial port implementation for mio
-
tokio-native-tls
TLS/SSL streams for Tokio using native-tls giving an implementation of TLS for nonblocking I/O streams
-
poll-promise
Poll the result of an async operation in a game or immediate mode GUI
-
crb
CRB | Composable Runtime Blocks
-
futures-bounded
bounding futures in size and time
-
cxx-async
interoperability between C++ coroutines and asynchronous Rust
-
pharos
Observer pattern which generates a futures 0.3 stream of events
-
hydra
A framework for writing fault tolerant, highly scalable applications with the Rust programming language
-
deno_unsync
A collection of adapters to make working with Tokio single-threaded runtimes easier
-
svix
Svix webhooks API client and webhook verification library
-
fmmap
A flexible and convenient high-level mmap for zero-copy file I/O
-
tokio_schedule
schedule tasks in tokio runtime
-
rusty_pool
Self growing / shrinking
ThreadPool
implementation based on crossbeam’s multi-producer multi-consumer channels that enables awaiting the result of a task and offers async support -
ipc-queue
FIFO queue described in fortanix-sgx-abi used for asynchronous usercalls
-
async-speed-limit
Asynchronously speed-limiting multiple byte streams
-
poem-openapi
OpenAPI support for Poem
-
ntex-h2
An HTTP/2 client and server
-
trait-variant
working with impl traits in Rust
-
fn_graph
Runs interdependent logic concurrently, starting each function when predecessors have completed
-
async-scoped
Spawn scoped (non 'static) asynchronous futures for async_std and tokio runtimes
-
async-native-tls
Native TLS using futures
-
scoped-futures
imposing upper bounds on Future lifetimes
-
reactive-mutiny
async Event-Driven Reactive Library with advanced & optimized containers (channels) and Stream executors
-
hirun
A concurrent framework for asynchronous programming based on event-driven, non-blocking I/O mechanism
-
async-tempfile
Automatically deleted async I/O temporary files
-
lamellar
asynchronous tasking runtime for HPC systems developed in RUST
-
c-ares-resolver
An asynchronous DNS resolver, backed by c-ares
-
rocketmq-client-rust
Apache rocketmq client
-
stream_throttle
Stream combinator, to limit the rate at which items are produced
-
mcp-attr
declaratively building Model Context Protocol servers
-
hyper-multipart-rfc7578
multipart/form-data (RFC7578) for Hyper
-
pty-process
spawn commands attached to a pty
-
async-lsp
Asynchronous Language Server Protocol (LSP) framework based on tower
-
delay_timer
Time-manager of delayed tasks. Like crontab, but synchronous asynchronous tasks are possible, and dynamic add/cancel/remove is supported.
-
specta-typescript
Export your Rust types to TypeScript
-
tor-rpcbase
Low level functionality for Arti's RPC service
-
aggligator
Aggregates multiple links (TCP or similar) into one connection having their combined bandwidth and provides resiliency against failure of individual links
-
conogram
An async wrapper for Telegram Bot API
-
peace
zero stress automation
-
open-coroutine
efficient and generic stackfull-coroutine library
-
tokio-rustls-acme
Automatic TLS certificate management using rustls
-
celery
Rust implementation of Celery
-
peekable
reader and async reader, which enhance your network programming experience
-
local-waker
A synchronization primitive for thread-local task wakeup
-
executor-trait
A collection of traits to define a common interface across executors
-
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
-
fang
Background job processing library for Rust
-
triggered
Triggers for one time events between tasks and threads
-
safina
Safe async runtime
-
a10
io_uring library
-
actix-web-flash-messages
Flash messages for actix-web applications
-
hypercore
Secure, distributed, append-only log
-
busybody
Service Container and Dependency injector crate
-
viz
Fast, robust, flexible, lightweight web framework for Rust
-
partial-io
Helpers to test partial, interrupted and would-block I/O operations, with support for property-based testing through proptest and quickcheck
-
wg
Golang like WaitGroup implementation for sync/async Rust
-
interruptible
Stops a future producer or stream from producing values when interrupted
-
rustler
Safe Rust wrappers for creating Erlang NIF functions
-
async-ssh2-lite
Asynchronous ssh2
-
countio
Byte counting for std::io::{Read, Write, Seek} and its async variants from futures and tokio
-
tigerbeetle-unofficial
Safe high level async bindings to tigerbeetle client library
-
kube-lease-manager
Ergonomic and reliable leader election using Kubernetes Lease API
-
filebuffer
Fast and simple file reading
-
compio
Completion based async runtime
-
async-bincode
Asynchronous access to a bincode-encoded item stream
-
suppaftp-cli
FTP command line client, based on suppaftp
-
scc2
High-performance containers and utilities for concurrent and asynchronous programming
-
stakker
A lightweight low-level single-threaded actor runtime
-
rocketmq-filter
A filter for RocketMQ messages
-
tiny_kafka
A tiny Kafka client library with producer and consumer functionalities
-
noveum-ai-gateway
A high-performance AI Gateway proxy for routing requests to various AI providers, offering seamless integration and management of multiple AI providers
-
blockstore
An IPLD blockstore capable of holding arbitrary data indexed by CID
-
common-multipart-rfc7578
multipart/form-data (RFC7578)
-
ferrisgram
An elegent rust client for the Telegram Bot API
-
async-ringbuf
Async SPSC FIFO ring buffer
-
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
-
lcode
An application of terminal write leetcode.一个终端刷力扣的应用
-
tower-lsp-server
Language Server Protocol implementation based on Tower
-
gcra
A basic implementation of GCRA algorithm for rate limiting
-
poster
MQTTv5 client library written in Rust
-
ginepro
A client-side gRPC channel implementation for tonic
-
async-object-pool
object pool implementation that uses asynchronous synchronization primitives only
-
futures-channel
Channels for asynchronous communication using futures-rs
-
daktronics-allsport-5000
decoders for the Daktronics All Sport 5000's serial output
-
round-based
Driver for MPC protocols
-
stopper
an async stream and future stopper mechanism
-
syslog-rs
A native Rust implementation of the glibc/libc syslog
-
apalis-sql
SQL Storage for apalis. Use sqlite, postgres and mysql for background job processing
-
simple-git
git interface for gix suitable for async context (with tokio)
-
ghost_actor
GhostActor makes it simple, ergonomic, and idiomatic to implement async / concurrent code using an Actor model
-
aqueue
fast speed thread safe async execute queue
-
ruva
Event Driven Message Handling
-
mobc
A generic connection pool with async/await support
-
deduplicate
caching, asynchronous, request deduplication
-
sipper
A type-safe future that can notify progress
-
hedwig
message bus for Rust
-
rust-parallel
Fast command line app in rust/tokio to run commands in parallel. Similar interface to GNU parallel or xargs.
-
google-places-api
Unofficial Google Places API for rust
-
futures-rx
Rx implementations for the futures crate
-
fusio-parquet
Parquet reader and writer implementations for Fusio
-
async-graphql-rocket
async-graphql for Rocket.rs
-
rxr
Reactive extensions for event-driven applications
-
underway
⏳ Durable step functions via Postgres
-
jsoncall
asynchronous JSON-RPC 2.0 library leveraging Rust's type system
-
memberlist
A highly customable, adaptable, async runtime agnostic gossip protocol which helps manage cluster membership and member failure detection
-
another-rxrust
A different implementation than
rxRust
for easier use ofReactiveX
inRust
-
async_cache
Async refresh cache
-
mutringbuf
lock-free SPSC ring buffer, with in-place mutability
-
async-event
An efficient async condition variable for lock-free algorithms
-
get_chunk
File iterator or stream with auto or manual chunk size selection
-
tiny-tokio-actor
tiny actor library on top of tokio
-
swiftide-integrations
Fast, streaming indexing, query, and agentic LLM applications in Rust
-
actor-core-client
Rust client for ActorCore - the Stateful Serverless Framework for building AI agents, realtime apps, and game servers
-
slice_ops
A selection of useful slice operations
-
clamav-client
ClamAV client library with optional Tokio and async-std support
-
floxide-timer
Timer node abstractions for the floxide framework
-
tokio-eventfd
Linux eventfd for tokio
-
pexels-cli
client for the Pexels API
-
clia-async-openai
OpenAI (with rustls)
-
simple-pool
async pool for any kind of resources
-
pingora-timeout
Highly efficient async timer and timeout system for Tokio runtimes
-
nuclei
Proactive IO & runtime system
-
rh2
An HTTP/2 client and server
-
hakuban
Data-object sharing library
-
faktory
API bindings for the language-agnostic Faktory work server
-
async_io_stream
IntoAsyncRead on steriods
-
async-dropper
The least-worst ad-hoc implementation of AsyncDrop as a Derive macro
-
xan-actor
Akka actor
-
kompact
Kompics component model combined with the Actor model
-
mio_wasi
Lightweight non-blocking IO
-
dptree
An asynchronous event dispatch mechanism for Rust
-
hypercore-protocol
Replication protocol for Hypercore feeds
-
transform-stream
Lightweight async stream wrapper
-
async_executors
Implements Spawn, SpawnLocal and SpawnHandle for commonly used executors
-
reord
Run your tests multi-threaded, but in a reproducible way
-
ate
Distributed immutable data store with strong encryption and authentication
-
async-cuda
Async CUDA for Rust
-
ractor_actors
actors built with Ractor
-
springtime-di
Dependency injection framework based on automatic component discovery and runtime autowiring
-
ector
open source async, no-alloc actor framework for embedded devices
-
next-gen
Safe generators on stable Rust
-
b2_backblaze
basic async library to upload small files to backblaze b2 service
-
qutex
Synchronization mechanisms that rely on lock-free and other non-(thread)blocking techniques, such as Rust futures, to guarantee mutually exclusive or shared exclusive access to data
-
ya-gcp
APIs for using Google Cloud Platform services
-
page-turner
A generic abstraction of APIs with pagination
-
try-again
Retry synchronous and asynchronous operations
-
tokise
An asynchronous runtime compatible with WebAssembly and non-WebAssembly targets
-
smol
A small and fast async runtime
-
fundamentum-edge-daemon
The supported way to access Fundamentum's ecosystem from linux devices
-
irelia
wrapper around the native LoL APIs
-
mail-message
A program for easy, quick, and fault tolerant sending of emails from the command line
-
reactio
Low-Latency Event Driven Nonblocking Reactor Pattern
-
genawaiter2
Stackless generators on stable Rust
-
async-event-emitter
Lightweight AsyncEventEmitter
-
wiremocket
Websocket mocking to test Rust applications
-
monzo-lib
async Monzo client in pure rust
-
pi_async_buffer
Asynchronous Buffer for IO
-
lazy_async_promise
Primitives for lazily getting data from futures with tokio for immediate mode guis
-
girlboss
async job manager with progress tracking
-
netidx-protocols
Protocols built on top of netidx
-
async_cell
A Cell<Option<T>> that you can await on
-
tokio-par-util
running computations in parallel on top of Tokio
-
kafru
Python Celery-inspired queuing library for Rust, using cron for scheduling and SurrealDB for storing queues, metrics, and schedules
-
axum-extra
Extra utilities for axum
-
crossmist
Efficient and seamless cross-process communication, both synchronously and asynchronously
-
certsd
automated, asynchronous LE certificate issuer
-
eureka-mmanager
An Actix actor collection for downloading manga, chapters, covers from Mangadex
-
keyring-lib
High-level, asynchronous API for keyring-rs, a cross-platform Rust library to manage credentials
-
safina-timer
Safe async timers - ARCHIVED: Code moved to
safina
crate -
cassette
single-future, non-blocking executor intended for building state machines
-
elfo
An asynchronous distributed actor framework with robust observability
-
task-supervisor
Tokio tasks Supervisor
-
lighthouse-client
Client SDK for Project Lighthouse
-
rabbit-auto
Wrappers for lapin publishers and consumers
-
quick-protobuf-codec
Asynchronous de-/encoding of Protobuf structs using asynchronous-codec, unsigned-varint and quick-protobuf
-
mountain-mqtt
A no_std compatible, async MQTT v5 client for tokio and embedded use
-
postage
An async channel library
-
rust-multipart-rfc7578_2
multipart/form-data (RFC7578)
-
madsim-tokio
The
tokio
simulator on madsim -
ntex-files
Static files support for ntex web
-
vkapi2
vk api wrapper for rust
-
dynosaur
Dynamic dispatch for return position impl traits and async in Rust
-
bounded_join_set
A Concurrency-Limited JoinSet for Tokio
-
est
Extensions for the rust Standard library and Tokio
-
debounced
building delayed
Future
s and debouncedStream
s that wait a given duration before yielding the most recent item -
cargo-steady-state
Code generator for steady_state projects based on a structured dot file
-
meltdown
A lightweight service manager to help with graceful shutdown of asynchronous applications
-
mpi-sys
Message Passing Interface bindings for Rust
-
rio
GPL-3.0 nice bindings for io_uring. MIT/Apache-2.0 license is available for spacejam's github sponsors.
-
futures-timeout
that provides timeouts for futures and streams
-
rdkafka-sys
Native bindings to the librdkafka library
-
llm_client
easiest Rust interface for local LLMs
-
yield-progress
Combined progress reporting and cooperative task yielding
-
mini_exercism
Minimalistic Rust library to interact with the Exercism.org APIs
-
with-async-context
managing contextual data across async tasks
-
nebkor-maelstrom
synchronous client for creating Maelstrom distributed clients
-
mio-aio
POSIX AIO bindings for mio
-
futures-io
The
AsyncRead
,AsyncWrite
,AsyncSeek
, andAsyncBufRead
traits for the futures-rs library -
cyper
HTTP client library based on compio and hyper
-
corcovado
Non-blocking IO library
-
twilight-http-ratelimiting
Discord REST API ratelimiter implementations for the Twilight ecosystem
-
v_exchanges
Implementations of HTTP/HTTPS/WebSocket API methods for some crypto exchanges, using crypto-botters framework
-
kwi-kraken-rest
Unofficial kraken trading platform REST API implementation
-
image_search
designed to search Google Images based on provided arguments
-
unkey
An asynchronous Rust SDK for the Unkey API
-
turmoil
Simulation testing framework for distributed systems
-
ractor-supervisor
Supervisor module for ractor framework
-
containerd-client
GRPC bindings to containerd APIs
-
telers
An asynchronous framework for Telegram Bot API written in Rust
-
coc-rs
wrapper around the Clash of Clans public API
-
wgpu-async
Converts some WGPU callback methods to async methods
-
truba
The minimal tokio runtime based actors for Rust
-
messagebus
allows intercommunicate with messages between modules
-
flo_binding
Declarative binding library for Rust
-
async-lazy
A value which is initialized on the first access, with an async function
-
fourche
task queue named after a lion with forked tail (queue fourché), works with Redis
-
agnostic-net
Agnostic abstraction layer of
std::net
for any async runtime -
architect-tonic
A gRPC over HTTP/2 implementation focused on high performance, interoperability, and flexibility
-
flourish
Convenient and full-featured signals for Rust
-
mikrotik-rs
Asynchronous Rust library for interfacing with MikroTik routers
-
async-change-tracker
reactive change notifications using futures
-
actix-casbin
An Actix actor for casbin
-
firecracker-rs-sdk
🧨🦀🚀 The Firecracker Rust SDK. A pure Rust crate for interacting with Firecracker.
-
libmqm-default
IBM® MQ Interface (MQI) and MQ Administration Interface (MQAI) structure defaults
-
fama
Pipeline Manager
-
odem-rs
Object-based Discrete-Event Modelling in Rust using async/await
-
acton_test
Testing utilities for Acton agents, providing tools to help in the testing and validation of agent behavior
-
scuffle-context
Go-like context utilities for Rust
-
lemmy_db_views_actor
A link aggregator for the fediverse
-
sacs
Async Cron Scheduler for Tokio
-
qbittorrent_rust
An asynchronous library to interface with the qbittorrent WeBUI API
-
fundamentum-sdk-mqtt
MQTT client targeting Fundamentum IoT's MQTT broker
-
tools_interface
Abstractions of serveral Wikipedia/Wikimedia/Wikidata-related tools
-
serio
providing traits and utilities for typed IO using format agnostic serialization built on serde
-
tokio-stream
work with
Stream
andtokio
-
axum-standardwebhooks
Axum extractor that verifies signature for Standard Webhooks
-
colpetto
Async libinput wrapper
-
genawaiter
Stackless generators on stable Rust
-
yatis
T-bank Investment Sdk
-
rust-utils
Various utility routines used in the rust programs I have written
-
whirlwind
Collection of thread-safe, asynchronous data structures
-
tokactor
A actor model framework wrapped around tokio
-
rasi-spec
The Official RASI Specification Test Suite
-
stackfuture
wrapper around futures that stores the wrapped future in space provided by the caller
-
async_zmq
Async version for ZeroMQ bindings
-
streamunordered
An efficient async stream multiplexer
-
tros
Your tros from tarantool TX thread to tokio(..and others!)
-
cancel-safe-futures
Alternative futures adapters that are more cancellation-aware
-
async-transmit
Trait for transmitting data to peers asynchronously
-
interthread
Auto implementation of the Actor Model
-
miow
A zero overhead I/O library for Windows, focusing on IOCP and async I/O abstractions
-
async-openai-compat
OpenAI
-
stream-find
Add a
find
andfind_map
methods to any stream -
kioto-serial
Provide serial port I/O using tokio
-
ntex-neon
Async runtime for ntex
-
synchronized-writer
A tiny implement for synchronously writing data
-
tokio-tasks
Task managment for tokio
-
task_pool
Flexible abstraction for task-based composable multithreading
-
s3tui
TUI application for multiple s3 account operations
-
async-io-bufpool
Efficient asynchronous I/O operations with minimal idle memory overhead
-
infect
Intent/effect/task - A variation on the Model View Intent (MVI) and State Action Model (SAM) paradigms
-
futures-retry
Retry your Futures and Streams!
-
rseip
Ethernet/IP (CIP) client in pure Rust
-
tokio-process-tools
Interact with processes spawned by tokio
-
glommio
thread-per-core crate that makes writing highly parallel asynchronous applications in a thread-per-core architecture easier for rustaceans
-
pgp-lib
High-level, asynchronous API for rPGP, a pure Rust implementation of OpenPGP
-
basu
Eventbus crate with sync and async features
-
stream-cancel
interrupting asynchronous streams
-
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
-
simple_spawn_blocking
spawning blocking tasks more ergonomic
-
legend-saga
working with RabbitMQ and asynchronous operations
-
tor-rtmock
Testing mock support for tor-rtcomapt
-
rocketmq-runtime
Unofficial Rust implementation of Apache RocketMQ
-
ruloom
A thin wrapper around 'corosensei' that provides support for stackful coroutines in Rust (like Loom in Java or goroutines in golang)
-
mapped_futures
A collection of futures based on FuturesUnordered that supports insertion, removal and mutation of futures by key
-
ssip-client-async
Client API for Speech Dispatcher
-
fibers
execute a number of lightweight asynchronous tasks (a.k.a, fibers) based on futures and mio
-
async-injector
Reactive dependency injection for Rust
-
p2panda-stream
Stream-based methods to conveniently handle p2panda operations
-
lrcall
procedure call framework that is compatible with local and remote procedure calls
-
translators
Free Google Translator without API key and limits
-
linemux
providing asynchronous, multiplexed tailing for (namely log) files
-
bound
Wrap lock guards and other structs along with the locks or other data they are derived by shared reference from, in a struct you can pass around and store anywhere
-
async-rt
A small library designed to utilize async executors through an common API while extending features
-
discro
DISCRete Observables for asynchronous Functional Reactive Programming (FRP)
-
async-duplex-channel
An asynchronous duplex communication channel between multiple clients and a single responder in different asynchronous blocks
-
uactor
The fastest and most modular actor system that doesn't force you to pay for what you don't need
-
some_executor
A trait for libraries that abstract over any executor
-
daemon-base
A flexible and configurable Rust daemon library with lifecycle management, logging, callbacks, and optional async support. Works on Linux, macOS, and Windows.
-
vmcircbuffer
Double Mapped Circular Buffer
-
tokio-scheduler-rs
JobScheduler written with tokio runtime, automatic retry, hook and custom storage supported
-
cache_loader_async
A thread safe loading cache with async loader functions based on tokio
-
rs-event-emitter
simulate promise implementation for rust
-
pgboss
job queueing service
-
ctrlgen
Generate enums for message-passing services
-
context-async
context handle async future timeout or cancel
-
log-tracing-layer
Build your own custom tracing layer
-
hitomi_la
A hitomi.la API wrapper for Rust
-
xelf
A versatile Rust toolkit for self-use
-
tokio-zookeeper
Asynchronous client library for interacting with Apache ZooKeeper
-
sn_sdkg
Safe Network Synchronous Distributed Key Generation: enables dealerless section key generation
-
read_until_slice
AsyncBufRead::read_until extension to take a slice as a delimiter instead of a single u8
-
ora
Part of the Ora scheduler framework
-
mio-pidfd
mio support for Linux's pidfd
-
call-agent
A multimodal chat API library with tool support, OpenAI API compatible
-
lazy-pool
Experimental lazy object pool
-
mal-api
An asynchronous MyAnimeList (MAL) API library 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.
-
ads_client
An asynchronous, non-blocking ADS client
-
size-of-trait
determine the size of a future or trait impl at compile time
-
pasts
Minimal and simpler alternative to the futures crate
-
resident-utils
Resident program library
-
async-codec
creating async codecs
-
async-borrow
Async compatible ownership semantics using futures instead of lifetimes
-
multishot
An async, lock-free, reusable channel for sending single values to asynchronous tasks
-
kuska-handshake
Secure Scuttlebutt handshake + boxstream library
-
fmodel-rust
Accelerate development of compositional, safe, and ergonomic applications/information systems by effectively implementing Event Sourcing and CQRS patterns in Rust
-
peace_cli
Command line interface for the peace automation framework
-
notifier_hub
cannal subscribtion system
-
tokio-muxt
Timer for a limited set of events that multiplexes over a single tokio Sleep instance
-
forensic-adb
Tokio based client library for the Android Debug Bridge (adb) based on mozdevice
-
fluxor_cli
Fluxor CLI: a command-line tool that allows developers to quickly and efficiently create project starters for the Fluxor web framework
-
cron_tab
A cron job library for Rust
-
async_smux
Asynchronous smux multiplexing library
-
dist_tx
Rust language bindings for XA Distributed Transactions
-
effectum
An embeddable task queue based on SQLite
-
keen-retry
-- yet powerful -- zero-cost-abstractions & zero-copy lib for error handling & recovery
-
async-scgi
Async SCGI Client & Server
-
pierport
Urbit pier import protocol implementation
-
bleasy
High-level BLE communication library
-
crossbus
A Platform-Less Runtime-Less Actor Computing Model
-
rusturn
TURN server and client
-
async-mcp
Async Implementation of Model Context Protocol (MCP)
-
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)…
-
rxqlite-tests-common
A distributed sqlite database built upon
openraft
,sqlx
andsqlite
-
webex
Interface to Webex Teams REST and WebSocket APIs
-
async-rdma
async wrapper for RDMA ibvers lib
-
async_tasks_recorder
A struct for recording execution status of async tasks with async methods
-
singleflight-async
Singleflight in async style
-
async-fs
Async filesystem primitives
-
tasklet
An asynchronous task scheduling library
-
reactor-trait
A collection of traits to define a common interface across reactors
-
tonic-server-dispatch
A request-dispatch level for tonic-Server
-
pingora-openssl
OpenSSL async APIs for Pingora
-
s3-simple
fast and efficient s3 client for bucket operations
-
async-time-mock-async-std
Mockable time for use in async runtimes (async-std compatibility)
-
cbsk_socket_tokio
socket callback tool by tokio
-
passivized_vault_client
Vault Client - initialize and monitor Hashicorp Vault nodes
-
ffi_rpc
Use FFI with RPC
-
flowrs-core
Core components of the flowrs framework for directed graph workflows
-
aws-smithy-http-server-python
Python server runtime for Smithy Rust Server Framework
-
ics-watcher
A lightweight crate for monitoring ICS files or links and detecting changes, additions, and removals
-
patharg
Treat "-" (hyphen/dash) arguments as stdin/stdout
-
madsim-rdkafka
The rdkafka simulator on madsim
-
bb-downloader
async downloader for applications
-
robotxt
Robots.txt (or URL exclusion) protocol with the support of crawl-delay, sitemap and universal match extensions
-
drop-stream
A stream that wraps another stream with a closure that is called once it is dropped
-
pistones
An wrapper for the Piston code execution engine
-
upc
USB packet channel (UPC): provides a reliable, packet-based transport over USB
-
taskline
distributed task queue for Rust
-
aws-multipart-upload
AWS S3 multipart upload sinks
-
io_uring_actor
Near-zero overhead pipelined io_uring api via actor model so you don't have to use Arc<Mutex<IOUring>>
-
tokio_wasi
An event-driven, non-blocking I/O platform for writing asynchronous I/O backed applications
-
futures-signals-ext
Extension to futures-signals: MutableOption with combinators, spawning, predicate driven selections from SignalVec
-
async-fd-lock
Advisory cross-platform file locks using file descriptors with async support by spawning blocking tasks
-
pollable-map
Utilites for storing futures and streams in as a pollable map
-
flatty-io
Flat message transfer
-
heph
actor framework based on asynchronous functions
-
dora-coordinator
dora
goal is to be a low latency, composable, and distributed data flow -
retry-if
A tokio-compatible attribute-macro for decorating methods and functions with an exponential backoff
-
array__ops
A selection of useful array operations
-
cyclic_pipe
providing fixed-size, buffer pre-allocated cyclic pipe which support multi-producer and multi-consumer concurrent access
-
pupactor
actor model library built with tokio
-
biscuit-actix-middleware
Biscuit middleware for actix-web
-
warp-rate-limit
Rate-limiting middleware for the Warp web framework
-
mvsync
A standalone async and worker thread library, with expandable traits and command buffers
-
kube-coordinate
Kubernetes leader election using the coordination.k8s.io API
-
sids
sample actor-model scheme providing abstraction over actor types and messages that can be sent across threads
-
cooked-waker
A safe interface for creating async Wakers
-
actix-multipart-rfc7578
multipart/form-data (RFC7578) for Actix
-
chartr
cli for working with charts
-
serial-thread
Asynchronous, multithreaded serial port communication library using mpsc::cjhannels or async-channels for efficient data handling
-
task-local
storage for asynchronous tasks
-
pubnub
SDK for Rust
-
stressed
Universal CLI stress tester for competitive programming
-
async-openai-alt
OpenAI
-
containerd-shim-protos
TTRPC bindings for containerd shim interfaces
-
makepad-futures-legacy
Makepad futures legacy
-
nominatim
Bindings to the reverse geocoding API powered by openstreetmap
-
eventuals
Eventually consistent values
-
async-shared-timeout
Async timeout that can be reset and shared
-
mm1-proto-system
M/M/1! Queueing, do you speak it?!
-
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)
-
didcomm-rs
DIDComm messaging v2 specifications implementation: https://identity.foundation/didcomm-messaging/spec/
-
eventastic_postgres
An example postgres event store for eventastic
-
batch-channel
async channel that reduces overhead by reading and writing many values at once
-
acts
a fast, tiny, extensiable workflow engine
-
tactix
Actor Model based on Tokio
-
redis-work-queue
A work queue, on top of a redis database, with implementations in Python, Rust, Go, Node.js (TypeScript) and Dotnet (C#)
-
callback-result
Assists in converting the callback function's method of obtaining results into the await method
-
riker
Easily build fast, highly concurrent and resilient applications. An Actor Framework for Rust.
-
apis
Reactive, session-oriented, asynchronous process-calculus framework
-
elegant-departure
simplify graceful shutdown
-
jni-utils
Extra Utilities for JNI in Rust
-
futures-jsonrpcv2
Futures-based jsonrpc v2.0 crate
-
async-executor
Async executor
-
vss
A dead simple library to allow for easily reused shutdown signal handling
-
super-visor
ordered startup and shutdown for long-running tokio processes
-
async-tls
Asynchronous TLS/SSL streams using Rustls
-
bsky-cli
CLI application for Bluesky using ATrium API
-
scylla-rs
An async ScyllaDB driver built on an actor-model framework
-
act-locally
single-threaded async actors with ordinary functions as handlers and plainly typed messages
-
nosy
Change notification / observation / broadcast channels, with filtering and coalescing. no_std compatible.
-
fusio-object-store
the object_store integration of Fusio
-
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-task-tracker
graceful shutdown solution for tokio
-
wait
Syntactic sugar for calling async functions outside of an async context
-
kafka-threadpool
An async rust threadpool for publishing messages to kafka using SSL (mTLS) or PLAINTEXT protocols
-
pinky-swear
Futures and async/await-ready Promises
-
event_iterator
Asynchronous lending iterator
-
fastcgi-client
Fastcgi client implemented for Rust
-
act_rs
Act.rs is an actor library built to be used with the standard library and Tokio
-
ccny-course-catalog
A api wrapper for retrieving course related information from CUNY City College
-
prin
reverse proxy terminal utility
-
sigq
Queue that signals waiting consumers about node availability
-
gql_client
Minimal GraphQL client for Rust
-
starbase_events
Async and mutable event system
-
gprs
A set of filtered and optimized Rust libraries creates a foundation for building modern web frameworks
-
flatline
ssh-2.0 client library
-
stop-token
Experimental cooperative cancellation for async Rust
-
sluice
Efficient ring buffer for byte buffers, FIFO queues, and SPSC channels
-
moro-local
Experimental structured concurrency support for async Rust (similar to trio's nurseries). Works with non-Send futures on stable Rust.
-
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) -
syndicate
Syndicated Actor model for Rust, including network communication and Dataspaces
-
awaitgroup
Wait for a collection of async tasks to finish
-
async-blocking-stdio
std::io::std{in(), out(), err()} but async
-
hyperbee
Peer to Peer B-tree
-
stilgar
A lightweight, no-fuss, drop-in replacement for Rudderstack
-
tempo-rs
& minimal client to connect and interact with RTE's 'Tempo Like Supply Contract' API
-
omp
Rust SDK for developing open.mp gamemodes
-
tokio_kcp
A kcp implementation for tokio
-
rustygram
minimal and blazing fast telegram notification framework for Rust
-
zookeeper-async
An async ZooKeeper client
-
zino-orm
ORM for zino
-
openrouter_api
client library for the OpenRouter API
-
trale
minimalistic Rust async executor using io_uring for efficient, correct task execution
-
madruga
Retry resiliente com backoff
-
tub
Async Pool
-
tokio-shutdown
Wait for a stop signal across multiple threads
-
upstox-rust-sdk
SDK to access Upstox's Uplink v2 APIs programmatically
-
passivized_docker_engine_client
Docker Engine Client - manage and run containers, images, and volumes
-
zephyrus
A slash-command framework meant to be used with twilight
-
smolscale
A high-performance async-task scheduler
-
eventbuzz
A safe, fast, concurrent event publish/subscribe system based on tokio(async), inspired by Spring events
-
tower-lsp-f
Language Server Protocol implementation based on Tower
-
actix-mqtt-client
A MQTT client based on the actix framework
-
state_machine_future
Easily create type-safe
Future
s from state machines — without the boilerplate -
woddle
An async, synchronized, database-backed Rust job scheduler
-
async-tensorrt
Async TensorRT for Rust
-
async-dashscope
client for DashScope API
-
tokio-fluent
A fluentd client using tokio
-
hooch
A small async runtime that's been bootlegged for my projects
-
tokio-send-fd
A wrapper for tokio::net::UnixStream to send file descriptors
-
swiftide-agents
Fast, streaming indexing, query, and agentic LLM applications in Rust
-
brig
mar here, Briganteen—General Sir A. I. Magnus, the flapper-
-
libublk
building linux block device in userspace
-
parail
Easily switch between sequential and parallel
-
busstop
A command and query bus
-
monoio-codec
Codec for Monoio
-
letslogic
providing interaction with the Let's Logic API
-
winctx
A minimal window context for Rust on Windows
-
actman
Async Actor Model Library in Rust
-
tokio-serde-cbor
Integration of serde_cbor into tokio-io, to allow sending CBOR encoded frames across network (and possibly through other transports)
-
co_managed
Create managed sub coroutines. Managed sub coroutines will be cancelled when the parent exit
-
py_mcai_worker_sdk
AMQP Worker to listen and provide trait to process message
-
futures-scopes
Runtime agnostic, nestable, scopes for spawning non-static futures
-
fb_futures_ext
future crate extensions
-
async_logger
Asyncronous logger allows writing arbitrary slices to a memory buffer, which then processed by a writer in it's own thread
-
noosphere-into
Transformations of Noosphere content into various target formats
-
streamline
Reversible futures::Stream-based state machines
-
actix-rt
Tokio-based single-threaded async runtime for the Actix ecosystem
-
baton
channel for receiving updates per field
-
tower-batch-control
Tower middleware for batch request processing
-
persway
Sway IPC daemon
-
swait
Blocking on Futures
-
async-dropper-simple
struct-wrapper (i.e. AsyncDropper<T>) based implementation of AsyncDrop
-
claude-client
client for the Anthropic Claude API
-
streamcatcher
A thread-safe, shared (asynchronous), almost-lockless stream buffer
-
tower-layer
Decorates a
Service
to allow easy composition betweenService
s -
libmqm-sys
IBM® MQ Interface (MQI) and MQ Administration Interface (MQAI) bindings
-
zeke
a http library for rust built on top of tokio
-
ruchei
working with many streams
-
par_io
Parallel, async file I/O library with control over memory usage with no dependencies
-
futuresdr
An Experimental Async SDR Runtime for Heterogeneous Architectures
-
async_nursery
Primitive for structured concurrency
-
async-pipes
building concurrent data processing pipelines
-
rmp-futures
Async Rust MessagePack and MessagePack-RPC
-
okkoi
-
must_future
A wrapper future marked must_use - mainly to wrap BoxFutures
-
knien
Typed RabbitMQ interfacing for async Rust
-
overclock
A framework for building data-driven distributed systems
-
embedded-io-convert
Convert embedded-io-async types back to futures ones (nightly only)
-
ksoft
KSoft.SI api wrapper written in pure Rust
-
cgp-async
Async-generic primitives to support both sync/async in context-generic programming
-
async-ffi
FFI-compatible
Future
s -
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.
-
flag-bearer
Generic async semaphores
-
tipsy
Cross-platform IPC for Tokio
-
proxied
Asynchronous client connector for proxies
-
asynk-strim
Lightweight stream generator library
-
toy-rpc
An async RPC that mimics golang net/rpc's usage and supports both async-std and tokio
-
circulate
Lightweight PubSub framework that supports both sync and async
-
hexpm
client for the Hex package manager
-
specta-serde
Serde support for Specta
-
lua_actor
Lua Actor for Rust(sync/async)
-
secret-lib
Cross-platform, asynchronous Rust library to retrieve secrets from different sources
-
tokio-socketcan
Asynchronous Linux SocketCAN sockets with tokio
-
safina-threadpool
Safe thread pool - ARCHIVED: Code moved to
safina
crate -
riker-patterns
A collection of common actor patterns for Riker
-
process-lib
Cross-platform, asynchronous Rust library to run commands in pipelines
-
wasmbus-rpc
Runtime library for actors and capability providers
-
miniloop
The simpliest async executor without heap memory allocation
-
pi_rt_file
async file 的封装,添加了多线程竞争排序。
-
torznab-toolkit
A safe, multi-threaded, async toolkit for adding Torznab APIs to programs
-
async-minecraft-ping
An async Rust client for the Minecraft ServerListPing protocol
-
rendezvous
Easier rendezvous channels for thread synchronization
-
gcp_access_token
pure rust implimentation to get google cloud access token for servers with service account credentials
-
deepseek_rs
client library for the DeepSeek API
-
tbot
Make cool Telegram bots with Rust easily
-
tower-sessions-rusqlite-store
(tokio-)rusqlite session store for
tower-sessions
-
taski
async task DAG execution
-
thin_main_loop
Thin, cross-platform, main event loop. A building block for native GUI applications, among other use cases.
-
tokio_telegraf
Minimal async rust wrapper for the telegraf/influxdb protocol, based on Tokio
-
odem-rs-sync
Model-time synchronization facilities of the ODEM-rs simulation framework
-
asteroid-mq
An embeddable message queue system
-
algoroutine
Light-weight algebraic effect(algebraic goroutine) in Rust
-
aj
Background Job based on Actix
-
gem-rs
that serves as a wrapper around the Google Gemini API, providing support for streaming
-
cap-async-std
Capability-based version of async-std
-
rocketmq-remoting
Apache rocketmq remoting
-
nonblock
Read available data from file descriptors without blocking (e.g. sockets, streams, child stdout, named pipes)
-
hass-rs
An async websocket client for Home Assistant
-
rspl
A stream processor language
-
lichess-api
client for Lichess API v2.0.0
-
ntex-http
Http types for ntex framework
-
procsem
Semaphore used to lock thread/task-spanning sequence of operations
-
makepad-futures
Makepad futures
-
wora
A framework for building applications (daemons, etc) that run in different environments (Linux, Kubernetes, etc)
-
aiven_rs
sdk to interact with aiven-cloud apis
-
facebookexperimental/async_limiter
A Scalable, User-Friendly Source Control System
-
tokio-task-scheduler
A non-blocking task scheduler for Rust with fluent API, supporting interval-based and cron-like scheduling
-
piscina
generic pool that supports both sync and async
-
collections-futures
working with futures through collections types
-
termusix
A terminal-based music player with a user-friendly terminal UI, built with Rust
-
async-cron-scheduler
Runtime-agnostic async task scheduler with cron expression support
-
service-io
Build your service-server fast, easy (and without hosting!)
-
gcal_rs
A blazingly fast, hand written Google calendar API in Rust
-
senders_receivers
Senders/Receivers implementation for Rust
-
async-actor
actor framework for Rust
-
ed-journals
models for representing and parsing elite dangerous journal files
-
dbus-async
Asynchronous DBus library
-
tasky
fluent async task experiments
-
pcap-async
Async/Stream Extensions for libpcap
-
waitgroup
Async waitgroup for a collection of task to finish
-
actix-daemon-utils
Daemon Utilities by actix
-
callbag
spec for reactive/iterable programming
-
pin-utils
pinning
-
stund
An SSH tunnel maintenance daemon
-
dialectic
Transport-polymorphic, asynchronous session types for Rust
-
ractor_cluster
Distributed cluster environment of Ractor actors
-
openraft-rocksstore
A rocksdb based implementation of the
openraft::RaftStorage
trait -
tasc
A minimnal, asynchronous threadpool
-
tokio-lxi
LXI protocol abstractions for Tokio
-
actix-limitation
Rate limiter using a fixed window counter for arbitrary keys, backed by Redis for Actix Web
-
iroh-io
async local io
-
simple-cmd
command line utility for spawning commands
-
rust-paper
Rust Wallpaper manager from ( https://wallhaven.cc/ ) for Linux/UNIX only
-
forked-tarpc
An RPC framework for Rust with a focus on ease of use
-
scoped-stream-sink
Easy way to make streams and sinks
-
aws-parameters-and-secrets-lambda
Cache AWS Secrets Manager secrets in your AWS Lambda function
-
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.
-
async-time-mock-smol
Mockable time for use in async runtimes (smol compatibility)
-
moxie
Incremental runtime for interactive software
-
navactor
A cli tool for creating and updating actors from piped input
-
futures-map
Futures-based and hashmap-based alogrithms
-
prokio
An asynchronous runtime compatible with WebAssembly and non-WebAssembly targets
-
scipio
A set of utilities to allow one to write thread per core applications
-
spin_on
inefficient Future executor
-
adventure
your great adventure for the various type of requests
-
recurring-tasks
Define tasks and run them in an app forever, ala cronjobs. And don't run already/still running tasks.
-
task_forge
A flexible and simple task pool for asynchronous execution
-
proxy-scraper
command-line tool for scraping proxy information
-
xtra
A tiny actor framework
-
koibumi-socks
A minimal SOCKS5 client library
-
rs_ctx
Context propagation for rs framework
-
cb_fut
Call function that return value via callback without a callback
-
kafka-rs
Native Rust Kafka client, built upon kafka-protocol-rs and Tokio
-
hydra-dashmap
A fork of dashmap for the hydra framework
-
async-sleep
Async Sleep
-
crb-agent
CRB | Composable Runtime Blocks | Agent
-
aa-sms
Send messages from with Andrews & Arnold’s SMS API
-
async_zip_futures
An asynchronous ZIP archive reading/writing crate using futures-rs
-
async-io-converse
Can conduct a conversation over any AsyncRead or AsyncWrite type with serde compatible types
-
monoio-rustls
Asynchronous TLS streams wrapper for Monoio based on Rustls
-
hollywood
actor framework
-
mfio
Flexible completion I/O primitives
-
mio-extras
Extra components for use with Mio
-
rucron
Job Scheduling Crate
-
elevatorpro
TTK4145 Real-time Programming elevator project, Group 25, spring 2025
-
kapacitor-udf
creating Kapacitor User Defined Functions (UDFs)
-
cbsk_socket_rayon
socket callback tool by rayon
-
handle
Trait for asynchronous context pipeline
-
goods
Async assets system
-
queen
message queue
-
miau
Async aware and extensible layered configuration system
-
yamaha-rcp
Remote control of Yamaha mixing consoles using TCP/IP networking
-
voiceflousion
that provides toolkit for Voiceflow AI bots integrations and pre-built functionality for quick integration with popular messengers
-
tokio-nsq
NSQ client built on Tokio. Tokio NSQ aims to be a feature complete NSQ client implementation.
-
crius
hystrix-like circuit breaker
-
realhydroper-lsp
Language Server Protocol implementation based on Tower
-
background-jobs-sled
Sled storage backend for background-jobs
-
async-dispatcher
async runtime based on a pluggable dispatcher
-
cbsk_run
async pool tool
-
elfo-test
Test utils for the elfo system
-
ultra-batch
Tokio-based library to batch and cache database queries or other data lookups
-
fluvio-async-tls
Asynchronous TLS/SSL streams using Rustls
-
stackful
Bridge between sync and async
-
iap
async google/apple receipt validation using hyper
-
suika_utils
A small utility library for the suika web stack
-
tokio-util
Additional utilities for working with Tokio
-
async_dag
An async task scheduling utilitiy
-
any-mpsc
An mpsc that allows arbitrary types to be passed through
-
cloudflare_dyndns
DynDNS client for Cloudflare
-
izihawa-common-multipart
multipart/form-data
-
ipc-rpc
A wrapper over servo/ipc-channel which provides many high level features
-
futures-executor
Executors for asynchronous tasks based on the futures-rs library
-
async-priority-channel
An async channel where pending messages are delivered in order of priority
-
rumqttlog
kafka inspired rumqtt's mqtt commitlog
-
nanopore
A minimalist async runtime based on io_uring (Linux) and I/O rings (Windows)
-
rx_rust_mp
A protoype implementation of the ReactiveX API in Rust using a message passing approach
-
tower-sesh
A Tower middleware for strongly typed, efficient sessions
-
async-defer
Asynchronous Deferred Calls
-
viz-router
The router for Viz
-
aoc_leaderbot_lib
Support library for aoc_leaderbot, an Advent of Code leaderboard-watching bot
-
sonor
controlling sonos speakers
-
compio-net
Networking IO for compio
-
shutdown-handler
A shutdown handler that allows all parts of an application to trigger a shutdown
-
tokio-stream_wasi
work with
Stream
andtokio
-
mlua-luau-scheduler
Luau-based async scheduler, using mlua and async-executor
-
fb_futures_01_ext
Extensions for future 0.1 crate
-
peace_item_model
Data types for resource interactions for the Peace framework
-
async-net
Async networking primitives for TCP/UDP/Unix communication
-
charred
char checking
-
bing_client
Async reverse client for Bing copilot
-
lictool
that will help you quickly add a spdx license to your project right from the command line
-
prometheus-utils
built on top of the prometheus crate
-
tokio-rayon
Mix async code with CPU-heavy thread pools using Tokio + Rayon
-
orengine
Optimized ring engine for Rust. It is a lighter and faster asynchronous library than tokio-rs, async-std, may, and even smol
-
yaaral
async runtime abstraction library
-
hypixel_api
Generic wrapper around the hypixel api (automatic rate-limiting on client-side)
-
synch
A basic asynchronous timer implementation that uses the cortex-m SysTick peripheral
-
springtime
Dependency injection based application bootstrapping and execution crate
-
clia-rcproxy
A lightweight, fast and powerful Redis Cluster Proxy written in Rust
-
send-future
Ergonomic and performant fix for https://github.com/rust-lang/rust/issues/96865
-
sparkle-convenience
A wrapper over Twilight designed to make it more convenient to use
-
rblx-godot
Roblox To Godot Project, allowing you to run Roblox games inside Godot
-
heim
Cross-platform framework for system information
-
eyeball-im
Observable collections based on the
im
crate -
mobc-surrealdb
Surrealdb support for the mobc connection pool
-
cancellation-token
C#'s CancellationToken API
-
borrow_mutex
Async Rust Mutex which does not require wrapping the target structure
-
openai_responses
Rust SDK for the OpenAI Responses API
-
roux-stream
A streaming API for the roux Reddit client
-
selectme
A fast and fair select! macro for asynchronous Rust
-
bipe
asynchronous I/O pipe
-
sharded-thread
Expirement for now
-
mio-uds
Unix domain socket bindings for mio
-
kowalski
A Rust-based agent for interacting with Ollama models
-
floxide
A directed graph workflow system in Rust
-
coroutine-state
Inspect the state of a Future created by an async function
-
async_async_io
AsyncRead
,AsyncWrite
traits but withasync fn
methods -
bongonet-runtime
Multithreaded Tokio runtime with the option of disabling work stealing
-
esrc
Primitives for implementing event sourcing and CQRS systems
-
rustun
implementing STUN server and client asynchronously
-
safina-executor
Safe async runtime executor - ARCHIVED: Code moved to
safina
crate -
fure
Retrying futures using different policies
-
requiem
Actor framework for Rust
-
async-task-tracker
A task tracker used for waiting until tasks exit
-
simple-delay-queue
delay queue for Tokio
-
monoio-thrift
Thrift for Monoio
-
ordered-stream
Streams that are ordered relative to external events
-
axiom
Implements a highly-scalable and ergonomic actor system for Rust based on the best of Erlang / Elixir and Akka
-
swimos_trigger
SwimOS Asynchronous Trigger
-
side-futures
Send future for execution on the runtime that may be in a different thread
-
joyent-tokio-zookeeper
Asynchronous client library for interacting with Apache ZooKeeper
-
luis_sys
FFI bindings for Microsoft LUIS API
-
extend_mut
extending exclusive references
-
mm1-common
M/M/1! Queueing, do you speak it?!
-
tokio-mc
communication with PLCs using the MC protocol
-
lwactors
Lightweight actors for Rust using futures-rs
-
sfio-tokio-ffi
An oo-bindgen model for using Tokio in an FFI environment
-
maelstrom-node
Maelstrom Rust node framework
-
tower-memlim
Tower based middleware layer to limit requests based on the host's computer memory usage
-
timer-lib
A feature-rich Rust library for creating and managing timers
-
my-awesome-rabbitmq-lib
working with RabbitMQ and asynchronous operations
-
mamenoki
Complete implementation of a Beanstalkd client based on the Tokio runtime
-
stakker_mio
Mio I/O polling integration for the Stakker crate
-
proxycurl-linkedin-rs
client for the Proxycurl LinkedIn API
-
switchboard
Enables inter-process communiucation via queues and wakers
-
thread-async
Execute a task in a new thread and await the result asynchronously
-
tokio-file
Asynchronous file I/O for Tokio
-
ethercat-device-control
A command line utility to control Ethercat devices
-
ng-repo
Repository library of NextGraph, a decentralized, secure and local-first web 3.0 ecosystem based on Semantic Web and CRDTs
-
linkd
actor model framework that takes inspiration from OTP in the erlang ecosystem
-
parity-tokio-ipc
Interprocess communication library for tokio
-
async-observable
Async & reactive synchronization model to keep multiple async tasks / threads partially synchronized
-
peace_resource_rt
Runtime resources for the peace automation framework
-
flowync
multithreading a/synchronization
-
agnostic
abstraction layer for any async runtime
-
baildon
B+Tree library
-
telegram-bot-ars
creating Telegram bots
-
futures-test
Common utilities for testing components built off futures-rs
-
hackdose-server
A server to control smart plugs using data from smart meters
-
medea-reactive
Reactive mutable data containers
-
safina-sync
Safe structs for sharing or sending data between async tasks - ARCHIVED: Code moved to
safina
crate -
releez
run application release-checklist safely
-
async_closure
utilizes the nightly-only feature async_fn_in_trait to imitate async_closures
-
dd-tracing-layer
Send your logs to Datadog
-
acu
building asynchronous actors
-
wiremock_logical_matchers
Logical matchers for use with wiremock
-
futures-ticker
An asynchronous recurring time event
-
elfo-configurer
Loads and distributes configs across the elfo system
-
msq
legacy Master Server Query Protocol
-
bp3d-threads
threading library intended to simplify concurrency in BP3D
-
space-traders
Async SpaceTraders API client for Rust
-
akinator-rs
wrapper around the undocumented Akinator API
-
async-unsync
asynchronous, unsynchronized (thread-local) channels and semaphores
-
ora-timer
Part of the Ora scheduler framework
-
futures-test-preview
Common utilities for testing components built off futures-rs
-
iceyee_logger
Logger
-
metatrait
RPITIT Monads
-
xilinx-dma
Userspace Xilinx AXI DMA Interface
-
reducer
A predictable reactive framework for Rust apps
-
async_msp_cli
Async msp cli for iNav and BetaFlight
-
ticque
Take a queue for a resource
-
futures-ratelimit
Bounded flavors of futures' FuturesUnordered and FuturesOrdered
-
until_needle
An extension to the BufRead trait that allows reading until a specified pattern (needle) is found
-
kvarn_async
Async utilities used in the Kvarn web server
-
noosphere-storage
Pluggable backing storage for the Rust Noosphere implementation
-
yosemite
Asynchronous SAMv3 library
-
async-variadic
async variadic functions in Rust with trait bounds
-
xtor
Async Actor framework for Rust which is blazing fast and rock solid
-
fork_stream
Clone any stream
S
where<S as Stream>::Item: Clone
-
tokio-agent
Agents are a simple abstraction around state, inspired by Elixir's Agent
-
actix_async_handler
Support for async syntax for Actix
-
register-count
Counting
Register
s created by aCounter
-
tor-log-ratelim
Facility for rate-limiting log messages in Arti
-
stdin-nonblocking
Dependency-less non-blocking stdin reader using background threads. Supports streaming and immediate fallback defaults.
-
tokio-graceful-shutdown-without-anyhow
perform a graceful shutdown on a Tokio based service
-
there
planning and executing commands on local and remote hosts
-
tk-listen
A set of helper futures allowing to listen TCP (or unix) socket with resource limits and proper error handling
-
viaduct
A duplex communication channel between a parent and child process, using unnamed pipes
-
tokio-context
Contexts for cancelling asynchronous tasks using tokio
-
trillium-tokio
tokio runtime adapter for trillium.rs
-
oneshot-handshake
providing a symmetric one time use channel type
-
compio-driver
Low-level driver for compio
-
tokio-stdin-stdout
Thread- and future::sync::mpsc-based AsyncRead/AsyncWrite stdin/stdout with little buffering
-
safina-net
Safe async network functions - ARCHIVED: Code moved to
safina
crate -
slock
An async mutex that never deadlocks
-
futures_codec
encoding and decoding frames using
async/await
-
async_counter
Counter that implements a future to await on specific value
-
tokio-zmq
Futures abstractions for ZeroMQ on the Tokio event-loop
-
rusty_tarantool
Tarantul async client based on tokio framework
-
kvarn-quinn-proto
Temporary Kvarn fork: State machine for the QUIC transport protocol
-
gmf
An RPC library using Glommio and Tonic. Note: This package only works on Linux.
-
tokio-hrtime
Hires timers for tokio
-
pingora-runtime
Multithreaded Tokio runtime with the option of disabling work stealing
-
laststage
fast, durable, high concurrent HashMap
-
async-raft
An async implementation of the Raft distributed consensus protocol
-
zeroconf-tokio
Tokio-based wrapper around the zeroconf crate, which provides mDNS service discovery and registration capabilities
-
maikklein/unreal-api
Rust integration for Unreal Engine 5
-
ntex-rt
ntex runtime
-
rxqlite-lite-common
A distributed sqlite database built upon
openraft
,sqlx
andsqlite
-
hydra-websockets
A websocket server for the hydra framework
-
wtx-ui
Different user interfaces for WTX
-
hl7-mllp-codec
A Tokio codec for HL7 Minimal Lower Layer Message Transport protocol (MLLP)
-
sprinter
Run parallel queued tasks
-
work-steal-queue
Concurrent work-stealing queue, implemented using st3 and crossbeam-deque
-
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…
-
tobytcp
A little library for sending messages over a tcp stream
-
wait-for-me
Async CountDownLatch
-
io-tether
A small library for defining I/O types which reconnect on errors
-
this-state
way to store state in a thread-safe manner as well as a way to asynchronously wait for state changes
-
volo-http
HTTP framework implementation of volo
-
tokio-io-rewind
rewind tokio::io::AsyncRead and tokio::io::AsyncWrite streams
-
pw-telegram-bot-fork
creating Telegram bots
-
sched-callback
async callback scheduling
-
negahban
🧐 A simple file watcher, based on
notify
, designed to be fast, easy-to-use and async friendly -
deadpool-lapin
Dead simple async pool for lapin
-
git-next-server-actor
Server actor for git-next, the trunk-based development manager
-
quick_crawler
QuickCrawler is a Rust crate that provides a completely async, declarative web crawler with domain-specific request rate-limiting built-in
-
promising-future
Promise/Future pairs
-
prost-codec
Asynchronous de-/encoding of Protobuf structs using asynchronous-codec, unsigned-varint and prost
-
anchor-chain
A statically typed async framework for building LLM-based applications
-
async_io_utilities
An asynchronous IO utilities crate powered by
tokio
-
pcat
A dead-lock free parallel cat implementation
-
webhdfs
Hadoop WebHDFS client library
-
mini-c-ares-resolver
An asynchronous DNS resolver, backed by mini-c-ares
-
blec
cross-platform ble client library based on btleplug
-
zeebe
client for defining, orchestrating, and monitoring business processes across microservices using Zeebe
-
aktors
Driver for derive-aktor
-
phoenix_channels_client
async-ready client for Phoenix Channels in Rust
-
fates
creating reactive declarations
-
rt-local
Thread local asynchronous runtime working with platform-specific event loops
-
affair
A Tokio-based worker abstraction layer
-
prevayler-rs
System prevalence in rust
-
leptos_async_signal
Async signal for leptos Rust web framework
-
rspc-axum
Axum adapter for rspc
-
funfsm
An FSM library where the states are functions
-
curseforge
A straightforward asynchronous wrapper around the CurseForge Core API. Public API is subject to change before 1.0.0.
-
cooper
in-process, async Actor library for Rust
-
mediator
pattern in Rust
-
async-xml
deserializing XML data asynchronously
-
libevent
Rust bindings to the libevent async I/O framework
-
yrs
High performance implementation of the Yjs CRDT
-
waker-waiter
async runtimes interoperate with arbitrary futures
-
pausable_future
Pausable and resumable future, useful in background tasks
-
terminusdm
Terminus Download Manager. Download files, resume interrupted downloads, and keep a history of your downloads - within terminal UI.
-
fbinit-tokio
detail of fbinit crate
-
split-stream-by
Stream extension crate for splitting a Stream into two per a predicate
-
typed-emitter
Typed Async event emitter
-
async_object
Async Object wrapper
-
rocketmq-store
Storage layer for Apache RocketMQ in Rust
-
aoc_leaderboard
Strongly-typed wrapper for Advent of Code leaderboard data
-
heph-inbox
Bounded capacity channel designed to be used as inbox for actors. Also supports one shot channels.
-
futures_cbor_codec
A codec for framing an AsyncRead/AsyncWrite with cbor for all types that are serializable with serde
-
compio-fs
Filesystem IO for compio
-
tokio-snappy
Wrap rust-snappy as a async stream in tokio
-
bonsaimq
Message/job queue based on bonsaidb, similar to sqlxmq
-
rusty_falcon
Rust bindings for CrowdStrike Falcon API
-
toni
Fast and modular web framework for scalable applications
-
plumbing
An async abstraction to pipeline requests through a channel
-
stream-ext
An extension trait for Streams that provides a variety of convenient combinator functions
-
linked-futures
Link futures into a block, which stops all of the included futures when any of the futures complete
-
client-util
Help you to build requests and handle responses by several extension trait!
-
paranoid-hash
A Hashing Library For Those Paranoid With Their Security
-
ticks
ergonomic Rust wrapper for the TickTick Open API
-
unblock
A thread pool for isolating blocking in async programs
-
async-rate-limit
Common traits for rate limiting and implementations in async contexts
-
tokio_gen_server
Elixir/Erlang-GenServer-like actor on the Tokio runtime
-
async_singleflight
Async singleflight
-
tokio-shared
Share tokio Runtime bwtween dylibs
-
bubbles
Bubble integration server for powder diffraction
-
lalamove-rs
An unofficial Lalamove API crate for rust. It's still in development; PRs welcome!
-
scoped_async_spawn
spawn non-static futures
-
madsim-real-tokio
An event-driven, non-blocking I/O platform for writing asynchronous I/O backed applications
-
nsq-client
Rust client for the NSQ realtime message processing system
-
sendgrid-async
An async-std based client for sending emails with SendGrid
-
tokio_delayed_queue
Asynchronous delayed queue for Tokio runtime
-
wasmflow-packet
encapsulating the message packets sent across Wasmflow components
-
tokio-process-stream
that wraps a tokio::process into a tokio::stream
-
async_progress
Create sync points across async tasks
-
tigerbeetle-unofficial-core
Safe low level callback-based async bindings to tigerbeetle client library
-
reception
creating TCP listeners that spawns clients providing model abstraction layer
-
limitation
A rate limiter using a fixed window counter for arbitrary keys, backed by Redis
-
plumb
A functional, async pipeline framework
-
mofo
Multiple Ongoing Futures Object - an abstraction for easily managing ongoing child tasks with futures
-
visiting_ref
Container types that asynchronously return ownership of a value to another context upon exiting scope
-
napmap
Async HashMap that halts requester tasks until the requested data is accessible
-
lendpool
lock-free library for allowing safe and concurrent access to a group of objects
-
future-utils
Extensions to Rust's Future and Stream traits
-
xtra-addons
Add-on functionality (Broker, Registry) for crate xtra
-
bisync
write async-generic code
-
event-listener-strategy
Block or poll on event_listener easily
-
nolocal-block-on
futures_lite::future::block_on that can run without using thread-locals
-
lookit
Asynchronously connect to devices
-
discern
implementing the Command Query Responsibility Segregation (CQRS) pattern
-
stream-broadcast
Runtime independent broadcast, which only polls it's underlying stream if no pending data is available
-
tokio-stream-multiplexor
Stream Multiplexor for tokio with a tcp like interface
-
async-copy-progress
Asynchronous copying with progress callbacks
-
rl-tokio
In-process token-bucket rate limiter for async tokio runtimes
-
streammap-ext
StreamMap of Tokio with altered
next
that returns when stream is dropped -
connect
message queue abstraction over async network streams
-
zonyitoo/coio
Coroutine scheduler with non-blocking I/O support
-
futuristic
Extensions to the futures crate
-
saas-zmq
ZeroMQ tools by using Publish-Federation
-
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
-
geese_executor
Asynchronous executor with Geese event system integration
-
graceful-shutdown
Graceful Shutdown for async code
-
tarpc-copy
An RPC framework for Rust with a focus on ease of use
-
backie
Background task processing for Rust applications with Tokio, Diesel, and PostgreSQL
-
actix-signal
Manage the lifecycle of an actix actor with its address
-
scuffle-signal
Ergonomic async signal handling
-
futures-async-stream
Async stream for Rust and the futures crate
-
proq
Idiomatic Async Prometheus Query (PromQL) Client for Rust
-
blocking-permit
Permits and a thread pool for blocking operations
-
lib3h_zombie_actor
lib3h actor request tracking module
-
gandi-v5-livedns-api
Gandi LiveDNS Api
-
eventful
event sourcing in Rust
-
hls_lfcd_lds_driver
Rust driver for ROBOTIS HLDS HLS-LFCD-LDS (LDS-01)
-
tezaursapi
api wrapper for tezaurs.lv
-
async-weighted-semaphore
An async weighted semaphore
-
web-push
Web push notification client with support for http-ece encryption and VAPID authentication
-
nats-handling
async NATS client library
-
tija_tools
tija_tools
is a Rust library providing a set of utilities designed to perform common tasks in Rust programming. This library is open for use and can be utilized in various applications… -
paperless-rs
An asynchronous Rust library for the Paperless-ngx document manager
-
async-hofs
Various extention traits for providing asynchronous higher-order functions
-
rants
An async NATS client library
-
stow
Cloud storage abstraction package for Rust
-
coachman
rust asynchronous task manager built on top of tokio framework
-
kay
Experimental high-performance actor system framework for Rust
-
multiserver
Rust multithread server samples
-
async_tasks_state_map
A struct for recording execution status of async tasks with async methods
-
speedracer
racing futures and ranking the results
-
capp
Common things i use to build Rust CLI tools for web crawlers
-
teloxide-core
Core part of the
teloxide
library - telegram bot API client -
coerce-k8s
Kubernetes discovery provider, automatically discover cluster peers hosted in Kubernetes, based on a configurable pod-selection label
-
lol-async
async html-rewriter
-
bastion-qutex
Synchronization mechanisms that rely on lock-free and other non-(thread)blocking techniques, such as Rust futures, to guarantee mutually exclusive or shared exclusive access to data
-
sodium
FRP (Functional Reactive Programming)
-
booru-dl
A command line tool to download images and tags txt from booru
-
veilid-async-tls
Asynchronous TLS/SSL streams using Rustls
-
borrow-count
Memory that can be shared with a smart pointer and then reaquired with a future
-
vesper
A slash-command framework meant to be used with twilight
-
kumoko
asynchronous server/client crate built on tokio for easy two-way streaming
-
backstage
A framework for building data-driven distributed systems
-
killswitch
used to broadcast a shutdown request
-
tokio-util_wasi
Additional utilities for working with Tokio
-
kioto-uring-executor
multi-threaded wrapper around tokio-uring
-
tidy-browser
Tidy up browser information
-
taskmanager
Manage groups of background tasks
-
lib-wc
Will's Programming Toolbox
-
miku-h2
An HTTP/2 client and server
-
clia_deepseek_rs
client library for the DeepSeek API (use rustls)
-
async-mavlink
An async adapter for mavlink conections
-
tarpc-plugins
Proc macros for tarpc
-
rumpsteak
Session types for asynchronous communication between multiple parties
-
dstream
DelayedStream - delays items and drops same items coming within given interval
-
eventador
lock-free pub/sub event-bus with sync and async APIs
-
async-log
Async tracing capabilities for the log crate
-
ref_count
Efficient, low-level asynchronous synchronization for real-time and embedded systems
-
deadpool-fantoccini
Dead simple async session pool for fantoccini
-
awaitable
type with input and output that can be stored in container
-
par-stream
Asynchronous parallel streams analogous to rayon
-
atomic-waker
A synchronization primitive for task wakeup
-
async-ctrlc
Async wrapper of
ctrlc
-
tokio-tower
Bridging the protocol gap between Tokio and Tower
-
actix-postgres
PostgreSQL integration for Actix framework
-
js-sys-futures
working with the futures and js-sys crates
-
mailbox_processor
A small little actor abstraction inspired by the FSharp Mailbox Processor which in turn was inspired by erlang
-
thread-waker
Waker implementation using current thread token
-
streamies
More features for your streams
-
fred
An async client for Redis and Valkey
-
f289ctrl
Communication library for Fluke 289 digital multimeter
-
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
-
async-sse
Async Server Sent Event parser and encoder
-
maybe-unwind
A wrapper of catch_unwind that also captures the panic information
-
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. -
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.
-
rust-freely
An asynchronous wrapper for the WriteFreely/Write.as API
-
piston_rs
An async wrapper for the Piston code execution engine
-
fundamentum-sdk-api
HTTP client targeting Fundamentum IoT devices RestAPI
-
deferred
help perform deferred execution of code logic
-
pirates
async RPC lib
-
indexed_db_futures
Future bindings for IndexedDB via web_sys
-
murray
A minimal actor definition macro using Tokio
-
tokio-prepend-io
Wrapper types that prepends data when reading or writing with AsyncRead or AsyncWrite
-
aggligator-transport-websocket
Aggligator transport: WebSocket
-
async-spin-sleep
providing a highly accurate asynchronous timer for multiple async tasks using spin sleep in a single thread
-
happyeyeballs
Happy Eyeballs implementation in Tokio (not RFC compliant atm)
-
napi_ext
Extends napi-rs with the ability to run local futures
-
moeval
a toy interpreter
-
deferred-future
模仿 jQuery.Deferred(),允许从 Future 实现类实例的外部对正在 pending 的 Future 对象进行 resolve 或 reject 处理。
-
xactor
actors framework based on async-std
-
tracing-orchestra
Give me more instruments!
-
noosphere-collections
Collection data types that are needed by an efficient implementation of Noosphere's IPLD data structures
-
pantry
Temporary storage for reusing values that may decay
-
maily
easy, quick, and fault tolerant sending of emails
-
tibrv
Bindings to the C library provided by TIBCO Rendezvous, a "high performance message oriented middleware" commonly used in the financial industry
-
tokio-fastcgi
FastCGI handler (responder, authorizer, filter) library for Tokio
-
init_system
Framework to wrap application init
-
pingora-rustls
RusTLS async APIs for Pingora
-
pi_async_file
A async file tools library
-
stream-guard
RAII wrapper around Stream that invokes a custom action on drop
-
pi_futures
feature select
-
zstd-framed
zstd seekable format compression and decompression. Supports sync and async I/O
-
tokio_interval
基于Tokio实现了 setInterval(callback, ms) 和 setTimeout(callback, ms) 类似于Javascript的API
-
io_uring_buf_ring
Help user create and manage io-uring buffer-ring
-
lifeline
dependency injection library for asynchronous message-based applications
-
ert
A combinator to control future execution order
-
lsp-codec
Tokio-compatible codec implementation for Language Server Protocol
-
swiftide-query
Fast, streaming indexing, query, and agentic LLM applications in Rust
-
clak
Minimal Rust implementation of SWIM group membership protocol
-
rsdns
DNS Client Library
-
isoprenoid
signals runtime framework backing flourish
-
dabus
Dynamic Aplication Controll Bus - an asynchronous, event based module system for thoes who want to move fast and *not* break things
-
async-notify
A general version async Notify, like
tokio
Notify but can work with any async runtime -
futures-boring
SSL streams for Futures built on top of the BoringSSL
-
gritlab
Gitlab rust API sdk
-
somen-language
somen parser combinator for languages
-
mycelium_lib
Mycelium DDM
-
tabs
A collection of asynchronous task abstractions, based on tokio
-
fe2o3-amqp-cbs
An experimental impl of AMQP 1.0 CBS extension
-
deploy-common
Common components for the
deploy
andfabric
crates -
key-lock
mutual exclusion by keys
-
reusable-box-future
A reusable
Pin<Box<dyn Future<Output = T> + Send>>
-
async-app
ergonomic approach to implement applications spawning event loops
-
random-access-storage
Abstract interface to implement random-access instances
-
sc2
StarCraft II Client API
-
set_timeout
allows efficiently executing futures after some delay has passed
-
git-event
Customizable event handler for updates in remote git repositories
-
rotor
The mio-based framework for doing I/O in simple and composable way
-
kernel
Abstract Reactive Streams
-
conva_ai
Rust SDK for using CONVA AI Copilots
-
bean_factory
bean factory,support inject reference bean
-
orsomafo
Event dispatcher crate
-
ianaio-file
Convenience crate for working with JavaScript files and blobs
-
rfm69-async
async driver for the rfm69 radio transceiver
-
tokio_util_watchdog
A watchdog utility for tokio runtimes
-
deluge
A highly concurrent stream library driving the underlying futures either concurrently or in parallel to process streaming operations as quickly as possible
-
tokio-bincodec
A fork of
tokio-bincode
-
witty-actors
Fork of quickwit-actors, Actor framework used in quickwit
-
elf_loader
A pure-rust library for loading all ELF format files from both memory and files
-
lunatic-distributed-api
control server implementation
-
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…
-
scoped_tasks_prototype
A quick-and-dirty attempt to get scoped tasks in Rust
-
tokio-uring
io-uring support for the Tokio asynchronous runtime
-
remote_config
Flexible crate for asynchronously loading configuration from remote source with caching and automatic revalidation
-
async-psec
Asynchronous PSEC implementation
-
future-bool
A bool one can await the changes
-
dwbhk
dwbhk-rs is a library for working with Discord Webhooks
-
xboot
static variables like module-level database connections can be initialized asynchronously before the program starts. / 在程序启动前通过异步函数初始化静态变量,如模块级数据库连接。
-
tokio-stream-multiplexor-fork
Stream Multiplexor for tokio with a tcp like interface
-
async-fuse
Helpers for fusing asynchronous computations
-
graus-db
A high-performance, thread-safe key-value embedded data store
-
aws-smithy-http-server
Server runtime for Smithy Rust Server Framework
-
task-exec-queue
A asynchronous task execution queue
-
pyo3-anyio
PyO3 utility bindings for Anyio's event loop
-
chunnel
Async mpmc(multi producer multi consumer) channel
-
alith-client
The Easiest Rust Interface for Local LLMs, and an Interface for Deterministic Signals from Probabilistic LLM Vibes
-
simple_futures
futures for use in async operations
-
allochronic-util
Private utility crate for allochronic and khonsulabs
-
tokio-tls-api
TLS/SSL streams for Tokio giving an implementation of TLS for nonblocking I/O streams
-
nyantrack-common
Common data types and functionality for NyanTrack
-
qp
Quick Pool: High Performance Async Generic Pool
-
gabelung
Branch an asynchronous stream of cloneable items into two
-
bisky
Bluesky API library
-
hypixel
Rust wrapper for the Hypixel public API
-
rust-stream-ext-concurrent
Concurrent behavior extensions for any futures::stream::Stream objects
-
mcprotocol-rs
Model Context Protocol (MCP)
-
mrwei
that implements the common promise primitive for rust based on std future
-
vkteams-bot-cli
VK Teams Bot API CLI
-
genawaiter2-macro
Convenience macros for generators (genawaiter2)
-
oni
Later on, there will be a framework for mmo games
-
rlua-async
Async support for rlua, via coroutines
-
tokio-easy-timer
A tokio-based task scheduler, with a user-friendly API
-
kvarn-quinn-udp
Temporary Kvarn fork: UDP sockets with ECN information for the QUIC transport protocol
-
idb
A futures based crate for interacting with IndexedDB on browsers using webassembly
-
futures-core
The core traits and types in for the
futures
library -
akt
An actors library for Rust and Tokio designed to work with async / await message handlers out of the box
-
crb-superagent
CRB | Composable Runtime Blocks | Agent Extensions
-
async-send-fd
A wrapper for async UnixStream's to send file descriptors
-
taurus
A WIP roguelike game being developed in Rust
-
epicenter
synchronous and asynchronous event dispatcher for Rust
-
blocking_pool
A thread pool for running synchronous I/O in asynchronous applications
-
signalr_rs
SignalR client based on actix web client and async await
-
blockz-futures
working with futures for the tokio stack
-
susync
An util crate to complete futures through a handle. Its main purpose is to bridge async Rust and callback-based APIs.
-
desaturate
This package aims to makes it easier to maintain a single code base for both regular and async functions
-
tokio-rustls-wasi
Asynchronous TLS/SSL streams for Tokio using Rustls
-
swarm-commander
Manage tons of commands asynchronously
-
async-hid
A async library for interacting with HID devices
-
cold-io
Event driven network io
-
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
-
simple-actor
Helper to write actor-based async code
-
futures-stream-ext
Asynchronous stream extensions for the futures(-core) crate
-
gcp_auth
Google cloud platform (GCP) authentication using default and custom service accounts
-
godot_tokio
The tokio-async runtime wrapped in a gdextention object to be used as an engine singleton in your gdext project
-
spin_future
Convert synchronous functions into valid but inefficient futures
-
termcandy
terminal GUI library
-
intercomm
Asynchronous inter-component communication library
-
srmw
Asynchronous single-reader, multi-writer
-
scuffle-future-ext
working with futures
-
flynn-openai
OpenAI
-
its_ok_to_be_block_on
A minimal implementation of block_on, to execute futures in a syncronous context
-
actix-interop
Use async/await syntax with actix actors
-
tokio-curl
asynchronous HTTP client using futures backed by libcurl
-
tokio-named-pipes
Windows named pipe bindings for tokio
-
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.
-
dbus-tokio
Makes it possible to use Tokio with D-Bus, which is a bus commonly used on Linux for inter-process communication
-
newsblur_api
NewsBlur-API
-
pingora-cache
HTTP caching APIs for Pingora proxy
-
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.
-
fut_rwlock
A read-write lock that is read and written via Futures
-
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 -
lending-stream
A lending version of Stream
-
agnostic-process
Agnostic abstraction layer of
std::process
for any async runtime -
tokio-transports
used for communication between processes
-
retry_future
Retry futures mechanism
-
async-rayon
Mix async code with CPU-heavy thread pools using Futures + Rayon
-
tokio-switching-sleep
A tokio Sleep with a switchable state
-
bongonet-timeout
Highly efficient async timer and timeout system for Tokio runtimes
-
encrypted-dns
A modern encrypted DNS server (DNSCrypt v2, Anonymized DNSCrypt, DoH)
-
go-zoom-kinesis
A robust AWS Kinesis stream processor with checkpointing and retry capabilities
-
napi_async_local
Extends napi-rs with the ability to run local futures
-
arta-tokio
Async abstractions implementation for Tokio
-
rudux
A Redux-like state management library for Rust
-
rad
A type-safe, high-level interface to librados using the low-level C bindings from ceph-rust
-
tokio-smoltcp
An asynchronous wrapper for smoltcp
-
agency
A small async actor framework
-
textmode
terminal interaction library backed by a real terminal parser
-
async-stream-lite
Proc macro-free async/await Rust streams
-
cannyls_rpc
RPC library for operating cannyls's devices from remote nodes
-
containerd-snapshots
Remote snapshotter extension for containerd
-
mlua_actor
Lua Actor for Rust(sync/async)
-
promise
future/promise library for rust
-
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
-
sidekiq-rs
Sidekiq compatible server in Rust
-
qbit-api-rs
A asynchronous Rust wrapper for qBittorrent Web API
-
loading-bytes
Load bytes from paths on native and WASM
-
anotify
Async iNotify Filesystem Watcher
-
smelling_salts
Abstraction over OS APIs to handle asynchronous device waking
-
promises
Effective, simple, lightweight Javascript promises in Rust
-
rexecutor
A robust job processing library
-
waterark
Watermark for implementing optimistic SSI (Serializable Snapshot Isolation) transactions
-
agner-reg
An actor toolkit inspired by Erlang/OTP (reg)
-
bevy_impulse
Reactive programming and workflow execution for bevy
-
riker-cqrs
Command Query Responsibility Separation for Riker applications
-
simple-process-stats
Get memory usage and CPU time on Linux and Windows
-
tonic-arcanyx-fork
A gRPC over HTTP/2 implementation focused on high performance, interoperability, and flexibility
-
worst-executor
A spin-loop like executor for async
-
m3u8_downloader
Application m3u8_downloader allows to download m3u8 HLS streams by master playlist link
-
futures-finally
that executes a future after the completion of a future or stream regardless of the value or outcome
-
heim-cpu
Cross-platform CPU information
-
selecting
Cross-platform wrapper over select
-
bon
Next-gen compile-time-checked builder generator, named function's arguments, and more!
-
gcs-rsync
rsync support for gcs with higher perf than gsutil rsync
-
tokio-rusqlite
Asynchronous handle for rusqlite library
-
async-interval
Async Interval
-
tokio-netstring-trait
A trait for tokios AsyncRead to easily read netstrings from streams
-
tag_nominatim
Bindings to the reverse geocoding API powered by openstreetmap
-
jarust
A janus client SDK in Rust
-
select-next-any
Alternative to futures::StreamExt::select_next_some that returns the None variant
-
italo-api
Rust binding for Italo API
-
jelastic-rs
Rust wrapper for the Jelastic API
-
syndicus
Publish/Subscribe with types for topics and subscriber (re)synchronisation
-
arti-rpcserver
Backend functionality for Arti's RPC service
-
mioco
Scalable, asynchronous IO coroutine-based handling (aka MIO COroutines)
-
activitystreams-traits
Traits for ActivityStreams 2.0 objects
-
odem-rs-util
Model elements and statistical tooling for the ODEM-rs simulation framework
-
await-group
Golang like WaitGroup implementation
-
async-signal
Async signal handling
-
futures-glib
Spawn futures on the glib event loop
-
celery-rs-core
Core utilities for a celery client and worker in rust
-
crown
jewel of rust libraries
-
pipebuf_websocket
PipeBuf support for websockets
-
messagebird-async
Wrapper around the message bird SMS API
-
rstorage
fast, durable, high concurrent HashMap
-
deadline
A one-macro crate to ensure assertions meet their deadlines
-
dslib
A simulation-based framework for teaching distributed systems
-
tower-sessions-file-store
Store sessions for Tower Session store on the file system
-
bevy_flurx
Allows you to use coroutine in Bevy
-
aggligator-monitor
Aggligator link monitor and speed test
-
futures-utils-lite
futures about utils in lite
-
yaanhyy_rust
cargo mod example
-
slim-futures
Asynchronous tools that intends for smaller binary size
-
async-nats-tokio-rustls-deps
Fork of Asynchronous TLS/SSL streams for Tokio using Rustls
-
jittr
A binary heap based jitter buffer implementation for zero latency udp/rtp streams
-
tokio-jsonrpc
JSON RPC 2.0 for tokio
-
futures-state-stream
A version of the futures crate's Stream which returns state on completion
-
rmw_ttlmap
Minimal async cache in Rust with support for key expirations
-
slog-scope-futures
slog-scope for
Future
s -
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.
-
nextgraph
client library. Nextgraph is a decentralized, secure and local-first web 3.0 ecosystem based on Semantic Web and CRDTs
-
task_yield
Executor-independent task yielding
-
settimeout
Creates a std::future::Future implementation to be ready at some point
-
csnmp
Community-based async (Tokio) SNMP client library
-
udp-stream
UdpSocket same as TcpStream
-
svix-webhook-with-clone
Svix webhooks API client with derive Clone added to Webhook struct
-
lunatic-messaging-api
Lunatic host functions for message sending
-
medina
An asynchronous web crawling engine
-
fb-api
Facebook Api abstraction for async rust
-
async-tun
Asynchronous allocation of TUN/TAP devices using async-std
-
stream-reconnect
Stream-wrapping traits/structs that automatically recover from potential disconnections/interruptions
-
netty-rs
allows exposes a simple-to-use API used to create stateful application level network protocols as both a client or server
-
async-jobs
Asynchronous job orchestration for Rust
-
raft-lite
understandable implementation of Raft consensus algorithm
-
mio-wakeq
mio support for custom event queue via Waker
-
zino-connector
Unified connector to data sources for zino
-
async-socks5
An async/.await SOCKS5 implementation
-
tokio-libtls
Tokio bindings for LibreSSL's libtls
-
count-write
An io::Write wrapper counting the number of bytes written
-
tokio-scoped
Scoped Runtime for tokio
-
poolparty
Added functionality for the
futures::executor::ThreadPool
futures executor -
wai
Windowing And Input
-
axum-core
Core types and traits for axum
-
bongonet-boringssl
BoringSSL async APIs for Bongonet
-
stateful_async_worker
Asynchronous stateful worker threads utilizable as futures
-
eventific
that gives you the needed building blocks for event sourcing
-
peace_webi_model
Web interface data types for the peace automation framework
-
fimxi
A multithreaded actor pattern framework
-
zippyst
Resolve zippyshare.com download links
-
async_msp_lib
Async msp library for iNav and BetaFlight
-
bastor
A wrapper helps implementing actor with Bastion more easier with self-implemented state
-
enjoin
Powerful syntax-level async join macro
-
mail-core
[mail/core] provides the Mail type for the mail crate (inkl. multipart mime bodies, builder and resource type)
-
eventually-postgres
Event Store implementation using PostgreSQL for the Eventually crate
-
russh-agent
Asynchronous ssh-agent client
-
task_simple
Execute functions in the background, both on desktop and web
-
awaken
Coalescing cross-thread wakers for mio and io_uring
-
bb8-bolt
A bolt-client adaptor for the bb8 connection pool
-
threader
A performant multithreaded future executor and event loop
-
openraft-memstore
A in-memory implementation of the
openraft::RaftStorage
trait -
serenity_ctrlc
Ctrl+C handler for serenity
-
browser-window
optionally async, optionally threadsafe, electron-like browser toolkit for Rust
-
futures-delay-queue
Async delay queue backed by async-std and futures-timer
-
stream-operators
a collection of selected rxjs operators for rust standard Stream
-
ardop_interface
Interface to the Amateur Radio Digital Open Protocol (ARDOP)
-
background-jobs-tokio
in-process jobs processor based on Tokio
-
nr-tracing-layer
Send your logs to New Relic
-
medusa-zip
A command-line interface to high-performance parallelized implementations of common zip file operations
-
leap_client_rs
Rust client library for the Leap Edge socket service
-
ruchei-route
Sinks with routes
-
task_scope
asynchronous runtime extension for supporting Structured Concurrency with task spawning
-
pseudoterminal
A cross-platform pseudoterminal implementation with async support
-
gentian
proc macro that transforms generators to state machines
-
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
-
sync_stream
Aggregate multiple streams by polling stream items in order, keeping the consumption of multiple streams in sync
-
rustpub
Activitypub types
-
fs
A Futures implementation for File System operations
-
deadqueue
Dead simple async queue
-
otdb
An open trivia database API wrapper
-
webrocket
A closure focused WebSocket server implementation
-
google-cloud-ai
A gRPC-based crate designed to interact with Google Cloud AI API
-
futures-dnsv2
A futures-based dns client implementation
-
safe-vk
create your own vk bot for conversations
-
chartr-core
building useful charts
-
vexide-async
The async executor at the core of vexide
-
tokio-task-manager
Allow an async Tokio application to gracefully shutdown, waiting for all tasks to finish
-
bme280-rs
query BME280 sensors over I²C
-
cdp-html-shot
capturing HTML screenshots using CDP
-
smoltimeout
A way to poll a future until it or a timer completes
-
discv5
p2p discv5 discovery protocol
-
dndx-fork-tokio-tun
Asynchronous allocation of TUN/TAP devices using tokio
-
aspartam
Minimalistic actor framework based on tokio, inspired by actix
-
futures-sink
The asynchronous
Sink
trait for the futures-rs library -
tokio-condvar
A Condition Variable for Tokio Applications
-
exit-future
Future that signals exit to many receivers
-
sigio
signal-based async io
-
fundamentum-edge-pfwd
The port forwarding tool for edge daemon
-
tus_async_client
native async client library to interact with *tus* enabled endpoints
-
cerebrust
working with NeuroSky devices under Rust
-
carboxyl
functional reactive programming
-
platoon
An experimental mini async runtime
-
browse
fast crawling framework
-
compio-io
IO traits for completion based async IO
-
simple-middleware
General purpose middleware crate
-
rseip-cip
common industry protocol for rseip
-
rspc
A blazing fast and easy to use TRPC server for Rust
-
hentai
API wrapper for nhentai.net
-
async-trait
Type erasure for async trait methods
-
tourniquet-tonic
Async native round-robin manager for remote services. Tonic integration.
-
aggligator-transport-usb
Aggligator transport: USB
-
csv-async
CSV parsing for async
-
contained-actors
contained is a research project implementing the proposed harmonic runtime for orchestrating cloud-native systems
-
tokio-xmpp
Asynchronous XMPP for Rust with tokio
-
smol-potat
Proc macro for smol runtime
-
agzip
Async compatible gzip (de)compressor
-
local-runtime
Thread-local async runtime
-
dark-std
asynchronous containers build on tokio. It uses a read-write separation design borrowed from Golang
-
pub-sub-client
Google Cloud Pub/Sub client library
-
shinyframework_jobs
Shiny Jobs
-
shared_cell
Interior mutability between concurrent tasks on the same thread
-
wasmflow-streams
encapsulating the message packets sent across Wasmflow components
-
elfo-utils
Some utils for the elfo system
-
iterstream
Converts Iterator into real asynchronous Stream
-
gen-stream
Generator-based streams for Rust and futures 0.3
-
pinarcmutex
PinArcMutex
type, for shared mutable access to pinned data -
dmds-tokio-fs
Dmds I/O handler interacts with the filesystem using Tokio
-
async-codec-lite
Adaptors from AsyncRead/AsyncWrite to Stream/Sink using futures
-
iou
io_uring bindings
-
nasu
Command-line utility which poll on remote addresses in order to perform status checks periodically
-
fil_actors_runtime_v10
System actors for the Filecoin protocol
-
patoka
Try this if you can decompose your problem into actors
-
haalka
ergonomic reactive Bevy UI library powered by FRP signals
-
wgp
waitgroup implementation
-
git-cinnabar
git remote helper to interact with mercurial repositories
-
futures-yamux
The yamux protocol implementation, rewritten from the ground up
-
cu
Low level bindings to cuda apis
-
parabuild
A parallel build utility for template heavy projects
-
heim-sensors
Cross-platform sensors information
-
change_stream
A Stream that only emits if the value is different
-
feature-extension-for-async-std
Feature extension for async-std
-
async-file-lock
Asynchronous file lock that can auto lock and auto seek
-
rs-copier
Copy and move files asynchronously
-
cf-turnstile
client for Cloudflare Turnstile
-
opencl-sys
OpenCL C FFI bindings for the Rust programming language
-
tokio-async-drop
macro to enable async drop in a tokio multithreaded runtime
-
asyncfd
Send and receive file descriptors over Unix domain sockets while maintaining Tokio AsyncRead and AsyncWrite
-
todc-net
Algorithms for message-passing (HTTP) distributed systems
-
tokio-async-write-utility
Some helper functions for types impl AsyncWrite
-
sntpc
making SNTP requests
-
async-trait-ext
a procedural macro for async traits
-
dataloader
Facebook's DataLoader using async-await
-
xdg-portal
implement for xdg-desktop-portal
-
futures-cache
Futures-aware cache backed by sled
-
uds
A unix domain socket crate that supports abstract addresses, fd-passing and seqpacket sockets
-
pwner
Process Owner crate that allows ergonomic access to child processes
-
rxqlite-sqlx-common
A distributed sqlite database built upon
openraft
,sqlx
andsqlite
-
eventsourcing
Event Sourcing for Rust
-
projections
Macro-free pin projections because why not?
-
async-component-components
async-component components
-
futures-cputask
Turn synchronous CPU-bound tasks into futures
-
some_local_executor
local executor
-
catalyzer
HTTP server framework
-
interruptible_polling
General purpose polling tasks with RAII-driven fast clean exits
-
async-timers
asynchronous timer primitives
-
kythera-lib
Kythera testing framework
-
async-native-tls-2
Native TLS using futures
-
async-lease
Essentially a futures-oriented Arc<Mutex<Option<T>>>
-
archflow
Create a streamable Zip archive
-
limitr
offering various rate-limiting algorithms such as Token Bucket, Leaky Bucket, and more
-
mail-core-ng
[mail/core] provides the Mail type for the mail crate (inkl. multipart mime bodies, builder and resource type)
-
surge-ping
Asynchronous ICMP ping library
-
tokio-pty-process-stream
wraps tokio-pty-process in order to provide a simpler API as a single stream object
-
sctp-proto
A pure Rust implementation of SCTP in Sans-IO style
-
async-waitgroup
Golang like WaitGroup implementation that supports both sync and async Rust
-
volo-macros
Volo's proc macros
-
suspend
A common mechanism for suspending a thread or a Future until notified
-
slings
A small async runtime based on io-uring for Rust
-
eyeball-im-util
eyeball-im
-
hydrolink
Lavalink client made with tokio independent of the Discord library, used in production by Hydrogen
-
crb-core-web
CRB | Composable Runtime Blocks | WEB
-
openai-api
OpenAI API library for rust
-
async-graphql
A GraphQL server library implemented in Rust
-
twinsies
Smart pointer providing 2-way joint ownership of an object
-
hyper-server
High level server for hyper and tower
-
fe2o3-amqp-management
An experimental impl of AMQP 1.0 management extension
-
bridge_updater_lib
A helper library to get Tor bridges with ease
-
django-query
Tools for mocking Django-style endpoints
-
serial-io
A serial port implementation
-
async-cuda-npp
Async NVIDIA Performance Primitives for Rust
-
async-zeroconf
Async library for wrapping Zeroconf implemenations for use with Tokio
-
process-stream
Thin wrapper around [
tokio::process
] to make it streamable -
atcoder
A template for Rust project
-
futures-dagtask
DAG-based Task Queue
-
kythera-actors
Kythera FVM WASM actor builder
-
zipit
Create and stream zip archives on the fly
-
async-throttle
Asynchronous Rate Limiting
-
juggle
Async task switching for cooperative multitasking in single thread environments with no_std support
-
future-by-example
Examples of common patterns using Future
-
bevy-tokio-tasks
integration of a Tokio runtime into a Bevy app for background processing
-
async-anyhow-logger
An easy crate for catching anyhow errors from an asynchronous function, and passing them to your logger
-
etcdv3client
etcdv3 client
-
spaad
Zero boilerplate actor systems with xtra
-
monoio-compat
A compat wrapper for monoio
-
futures-promises
Promises and Watched Variables for Futures
-
itla
ITLA (micro laser) non-blocking control library using embedded-hal
-
online
📶 Library to check your Internet connectivity
-
cntrlr
async embedded framework
-
kompact-component-derive
A derive macro for Kompact component definitions
-
futura
Helpers for working with futures
-
name-it
Give a name to async fn return types
-
ns-env-config
An env_logger-inspired one-stop configuration for name resolution based on abstract-ns. Reduces boilerplate and provides standard way to configure DNS for applications via
RUST_NS
environment variable. -
f189ctrl
Communication library for Fluke 189 digital multimeter
-
ockam_transport_uds
Unix Domain Socket (UDS) Transport for the Ockam Routing Protocol
-
yt-dlp
🎬️ A Rust library (with auto dependencies installation) for Youtube downloading
-
buffer-unordered-weighted
Stream::buffer_unordered where each future can have a different weight
-
swiftide-indexing
Fast, streaming indexing, query, and agentic LLM applications in Rust
-
rust-box
odd set of tools for Rust programming
-
prometheus-hyper
small Tokio/Hyper server to run Prometheus metrics
-
hash_cons
A type-safe hash-cons library
-
polaris-specification
Service Governance Specification
-
asyncio-utils
Support limit,skip on AsyncRead traits
-
atomic-actor
An
Actor
withasync fn
handlers -
troupe
modelling Rust applications with actors
-
c_mcai_worker_sdk
AMQP Worker to listen and provide trait to process message
-
futures-waitmap
future-based concurrent event waiting hashmap
-
quinn
Versatile QUIC transport protocol implementation
-
rosey-actors
Actor framework
-
tower-test
writing client and server
Service
tests -
lutetium
tokio based simple actor library
-
opentls
TLS connections with OpenSSL
-
mqi
Idiomatic IBM® MQ Interface (MQI) and MQ Administration Interface (MQAI) APIs
-
async-refresh
Create values that refresh automatically and asynchronously after a given duration
-
bluest
A cross-platform Bluetooth Low Energy (BLE) library
-
async-result
wrapper providing a convenient way to await a result, built on futures-channel's oneshot channel
-
attempt
do something over and over and over and over and
-
lunchbox
An async virtual filesystem interface
-
ockam_transport_websocket
WebSocket Transport for the Ockam Routing Protocol
-
north-config
North config is a multi source configuration crate designed as part of the North Microservice Framework
-
real-async-trait
A proc macro that uses experimental features to work around type erasure for async traits
-
eventually-redis
Event Store implementation using Redis, for Eventually crate
-
bevy-async-ecs
Asynchronous interface for Bevy ECS
-
lunatic-distributed
Node to node communication
-
compio-runtime
High-level runtime for compio
-
decoyssh
A compact and portable SSH tarpit server
-
edeltraud
thread pool for mixed tokio / threaded infrastructure with zero allocations and static dispatching only
-
sparkle-impostor
A third party crate for Twilight to execute Discord webhooks that clone an existing message
-
supplicant
Bindings for wpa_supplicant
-
tokio-utun
Utun bindings for Tokio
-
cancellable
providing a generic cancellable utility
-
named-retry
retrying fallible asynchronous operations
-
ffi_helpers
help make working with FFI easier
-
tunein
client to fetch radio stations from TuneIn
-
tokio-executor-trait
executor-trait implementation for tokio
-
libaio-futures
Straightforward Linux AIO using Futures/async/await
-
archlinux-repo
Arch Linux repositories parser
-
nbd-async
Block device drivers in userspace
-
aggligator-transport-bluer
Aggligator transport: Bluetooth on Linux
-
lease
Object pool that leases values and automatically returns them with async support
-
tokio-rustls-fork-shadow-tls
Asynchronous TLS streams wrapper for Tokio based on Rustls
-
relm
Asynchronous, GTK+-based, GUI library, inspired by Elm, written in Rust
-
b2sum-rs
Computing The Blake2b Hash of Files with any given Digest Size
-
quix
Distribution layer for actix
-
chokepoint
Generic stream transformer to simulate traffic / network congestion
-
turbocharger
Autogenerated async RPC bindings that instantly connect a JS frontend to a Rust backend service via WebSockets and WASM
-
axum-router-plugin
Shared library-based plugins for Axum
-
waihona
rudimentary cloud storage capabilities across major cloud providers
-
situwaition
Run a closure continuously, until is succeeds or times out
-
tower-async-layer
Decorates a
Service
to allow easy composition betweenService
s. An “Async Trait” fork from the original Tower Library -
v_exchanges_adapters
Implementations of HTTP/HTTPS/WebSocket API methods for some crypto exchanges, using crypto-botters framework
-
async-native-tls-alpn
Native TLS using futures
-
mio-signals
handling signals with Mio
-
vanilla_tokio_actor
Vanilla Tokio Actor
-
pingora-boringssl
BoringSSL async APIs for Pingora
-
twitch_api
talking with the new Twitch API aka. "Helix", EventSub and more!
-
histlog
hdrhistogram crate, provides off-thread serialization of HdrHistogram interval logs to file
-
chikatetsu
An(other) actor framework for Tokio
-
signald-rust
interface with Signald
-
pinned
Synchronisation primitives for !Send tasks
-
wookie
Async test/bench toolkit including single stepping executors. No-std compatible.
-
net-queue
A framework to abstract network queues
-
tokio-reactor-trait
reactor-trait implementation for tokio
-
tonic-side-effect
Tower service that can monitor if a Tonic request frame was produced prior to error
-
windmark
An elegant and highly performant async Gemini server framework
-
axum-session-manager
Session manager crate for Rust web framework 'Axum'
-
futures-rate
easy tools to help Rust applications guide critical resources or code paths from being overwhelmed
-
tower-async-bridge
Bridges a
tower-async
Service
to be used within atower
(classic) environment, and also the other way around -
event-source
Zero cost async immediate event dispatching
-
derive-tokio-io
Derive AsyncRead and AsyncWrite
-
lemmy_apub_lib
A link aggregator for the fediverse
-
bears
wrapper for the Bureau of Economic Analysis (BEA) REST API
-
mediatrix
Strongly typed, extensible event mediator
-
ferris_chats_data
data structures for ferris_chat
-
mini-telnet
Asynchronous minimal telnet library
-
vampirc-io
asynchronous, non-blocking, UCI protocol–based communication between chess UIs and chess engines
-
mikrotik_api
& minimal client to connect and interact with Mikrotik RouterOS API, usually exposed on port 8728
-
redis-cmd
An async Redis client for Rust built on redis crate
-
readwrite
Combine Read and Write into a single Read+Write object
-
icanhazdadjoke-sdk
An SDK to interact with the icanhazdadjoke Dad Jokes API
-
async-ucx
Asynchronous Rust bindings to UCX
-
wag
Go like sync.WaitGroup implementation in Rust. (sync/async)
-
peace_webi_output
Web interface output for the peace automation framework
-
hyper-futures
Compatibility layer for futures to use AsyncRead and AsyncWrite traits with hyper
-
taos
Driver for TDengine - a timeseries database and analysis platform
-
futures-io-preview
The
AsyncRead
andAsyncWrite
traits for the futures-rs library -
linux-io-uring
The
io_uring
library for Rust -
wnf
Safe bindings for the Windows Notification Facility
-
sampr
A message passing framework using actors
-
cdns-rs
A native Sync/Async Rust implementation of client DNS resolver
-
tokio-icmp-echo
Asynchronous ICMP pinging library
-
vino-packet
encapsulating the message packets sent across Vino components
-
heim-common
Common stuff shared across heim project crates
-
acril-rt
A lightweight single-threaded runtime for Acril actors
-
strawpoll
A wrapper to avoid spurious polling
-
akinator-py
Python bindings for akinator-rs
-
pegy
A derive based parser generator
-
avent
An async event system based on tokio broadcast
-
compio-buf
Buffer trait for completion based async IO
-
rust-cli-commands
-
completion-io
Core traits and types for asynchronous completion-based I/O
-
neo-email
The modern way to build emails services with Rust
-
async_buf_reader_utils
Adds additional functionality to the async-std crate for BufReader
-
relock
Distributed async locking using Redis
-
tokio_safe_block_on
ability to execute async code from a sync context, without blocking a tokio core thread or busy looping the cpu
-
ntex-codec
encoding and decoding frames
-
tokio_dual_stack
Dual-stack TCP listener based on tokio
-
puteketeke
An asynchronous runtime built on smol
-
mml-lib
Emacs MIME message Meta Language (MML)
-
micro_http_async
A small, lightweight and hassle-free crate using async to serve web pages or web apis with high performance and extremely low overhead
-
dynamodb-mutex
Use Dymanodb mutex library
-
wakerpool
lightweight object pool for lists of Wakers
-
axum-serde
multiple serde-based extractors / responses for the Axum web framework, also offers a macro to easily customize extractors / responses
-
thread_timer
cancelable timer with no external dependencies
-
retrier
A wasm-compatible retry library for futures
-
peace_webi_components
Web interface components for the peace automation framework
-
twitch-irc
Connect to Twitch chat from a Rust application
-
async-stream-packed
Asynchronous stream packed
-
serf-core
A decentralized solution for service discovery and orchestration that is lightweight, highly available, and fault tolerant
-
tower-actor
A
tower
middleware that creates aService
by passing messages to an actor -
c-ares
wrapper for the c-ares library, for asynchronous DNS requests
-
fibers_tasque
A
tasque
extension specialized forfibers
-
gpiocdev
Access GPIO lines on Linux using the GPIO character device
-
mysql_async
Tokio based asynchronous MySql client library
-
rtix
Actors with generators. Name up for grabs until I do something with it, or rust supports proper coroutines
-
async-read-length-limit
limit the size of an async read
-
limitation-actix-middleware
An Actix web middleware for rate limiting requests using a fixed window counter keyed on a header
-
async-pipe
Creates an asynchronous piped reader and writer pair using tokio.rs
-
qcongestion
Congestion control in QUIC, a part of gm-quic
-
epoxy_frp
The Reactive Glue for Frontend Applications
-
dbus-async-derive
Handler trait derive macro for dbus-async
-
futures-util-either
futures_util::future::Either Ext
-
async-handle
A reference-counted async RwLock
-
actix-bililive
stream-based bilibili live client library for the Actix ecosystem
-
bacon-ls
Bacon Language Server
-
hff-async-std
Hierarchical File Format: async-std support
-
asygnal
[WIP] Async-first signal handling, such as ctrl-c
-
crb-core-std
CRB | Composable Runtime Blocks | STD
-
dynalock
A lease based distributed locking algorithm with support for DynamoDB
-
conquer-struct
macros to perform concurrent future resolution, while populating struct fields
-
rexa
GraphQL MongoDB API builder
-
waker-set
waker set
-
agreed
Fork of async-raft, the Tokio-based Rust implementation of the Raft protocol
-
gritea
Gitea API sdk
-
jarust_plugins
A janus client SDK in Rust
-
rip-starttls
Sans I/O implementation of https://duesee.dev/p/avoid-implementing-starttls/
-
simplex-chat
API for the SimpleX Chat CLI
-
rexie
futures based wrapper around IndexedDB that compiles to webassembly
-
local-spawn-pool
Spawn
!Send
futures in a pool and await for all of them to finish. Standalone alternative totokio::task::LocalSet
. -
async-task-ffi
Task abstraction for building executors
-
blocksr
Drew's Rust library for (clang/objc) blocks
-
reactors
Performance-focused cross-platform asynchronous IO implementation
-
retainer
Minimal async cache in Rust with support for key expirations
-
cucumber-codegen
Code generation for
cucumber
crate -
openai-api-fork
OpenAI API library for rust
-
safina-async-test
Macro for running async tests - ARCHIVED: Code moved to
safina
crate -
shared_stream
easily cloneable streams
-
minehut
easy to use Rust wrapper for the Minehut API
-
rtx
zero-cost runtime-abstraction intended for use by Rust libraries to enable the Freedom of Choice between asynchronous runtimes
-
futures-fs
A Futures implementation for File System operations
-
valorant-assets-api
API Wrapper for valorant-api.com
-
async_job
async cron job crate for Rust
-
futures-time
async time combinators
-
tokio-rusqlite-new
Asynchronous handle for rusqlite library
-
x-bow
Precise State Management Library
-
timeware
timer used to schedule execution of closures at a given timestamp
-
app-queue
In-app persistent queue for asynchronous jobs
-
baildon-store
B+Tree CLI
-
librdkafka-sys
Native bindings to the librdkafka library
-
fixed-buffer-tokio
NOT MAINTAINED. This crate was replaced by the
fixed-buffer
crate withtokio
feature. -
arta-async-std
Async abstractions implementation for async-std
-
kvarn-tokio-uring
Temporary Kvarn fork: io-uring support for the Tokio asynchronous runtime
-
tokio-tasker
Lets you stop and join groups of Tokio tasks
-
futures-loco-protocol
Asynchronous Loco protocol stream for futures
-
bader-db
Key-value cache RESP server with support for key expirations
-
specta-jsdoc
Export your Rust types to JSDoc
-
islabtech-upw-sensor-v1
Rust client library for remote control of the ISLabTech UPW Sensor v1
-
agixt-sdk
Rust SDK for AGiXT - A powerful AI agent framework
-
tk-easyloop
A thread local loop and other loop helpers
-
tbon
TinyChain Binary Object Notation is a compact and versatile stream-friendly binary serialization format
-
mio-utun
Utun bindings for mio
-
aiur
Single threaded async executor with structured concurrency
-
eventastic
opinionated fork of Eventually-rs. It enforces the use of transactions and handles idempotency.
-
tlfs-crdt
tlfs crdt implementation
-
mailfred
Process emails as an HTTP server
-
esp-hal-embassy
Embassy support for esp-hal
-
rados_hi
Opinionated high-level wrapper for librados (Ceph)
-
handy_async
A handy library for describing asynchronous code declaratively
-
scoped_spawn
Full structured concurrency for asynchronous programming
-
requiem-server
Actix server - General purpose tcp server
-
reactive-messaging
Reactive client/server communications, focused on high performance
-
fd-queue
support fd passing on Unix sockets
-
tentacle
Minimal implementation for a multiplexed p2p network framework
-
zwuevi
communicate with the Tor control socket to generate ephemeral onion services
-
signalwire
The unofficial SignalWire SDK for Rust
-
task_scheduler
easilty schedule an FnOnce to run in the future
-
decrypt-cookies
A decrypt browser crate
-
tokio-tls-gmssl
TLS/SSL streams for Tokio using native-tls giving an implementation of TLS for nonblocking I/O streams
-
elfo-telemeter
Collects and exposes metrics of the elfo system
-
acril
A kitchen-sink actor framework
-
paggo
A small, fast, and safe in-memory database
-
email-lib
Cross-platform, asynchronous Rust library to manage emails
-
fil_actors_runtime_v9
System actors for the Filecoin protocol
-
makiko
Asynchronous SSH client library in pure Rust
-
tenorite
A concurrency abstraction library. Provides a client-server model for asynchronous workers
-
async-compat
Compatibility adapter between tokio and futures
-
async-recursion
Recursion for async functions
-
deadpool-amqprs
Dead simple async pool for amqprs
-
stream-flatten-iters
Flattens a stream of iterators into one continuous stream
-
gearbox
Excessive tooling for Rust, boosting productivity and operations
-
ekv
Key-value database for embedded systems, for raw NOR flash, using an LSM-Tree
-
async-trait-sync
Fork of async-trait with support to Sync future
-
kapacitor-multi-indicator-stream-udf
A multi-indicator stream UDF for Kapacitor
-
jira-api-v2
Jira Cloud platform REST API
-
delay
A collection of trait and classes to make your thread wait (and timeout)
-
openrazer
Asynchronous bindings to the OpenRazer daemon
-
swarm-discovery
Discovery service for IP-based swarms
-
scd4x-rs
query SCD4x sensors over I²C
-
nature
development support platform, it separates data definition from code, so it decouple the data from business system
-
reacher-fast-socks5
Fast SOCKS5 client/server implementation written in Rust async/.await (tokio)
-
libpool
threadpool from The Rust Programming Language
-
ws-gonzale
Naive websocket server implemented using async / await
-
abs_art
ABStraction of Asynchronous RunTime
-
aral
Async Runtime Aggregation Layer
-
rt-local-core
Thread local asynchronous runtime working with platform-specific event loops
-
launchpadlib
accessing Launchpad.net
-
gdext_coroutines
Run Rust Async functions and Coroutines in Godot 4.2+ (through GDExtension), inspired on Unity's Coroutines design
-
futures-task
Tools for working with tasks
-
futures-net
The futures-net library
-
somen
An asynchronous parser combinator
-
reqwest-eventsource
Helper to build an Eventsource using reqwest
-
async-mq
Zero-cost async-await abstraction of lapin AMQP client crate
-
protwrap
Thin protocol wrapper for network applications
-
axum-typed-websockets
axum::extract::ws with type safe messages
-
ockam_transport_core
Generic Transport primitives
-
component-future
implements the inner future protocol documented in the tokio docs
-
multi_stream
Aggregate multiple streams of different types in a single stream with an item type that is a tuple of the incoming stream items
-
gneiss-mqtt
Asynchronous and threaded MQTT(5) clients
-
tor-general-addr
Generalized socket address type used by Tor
-
tokio-boring
SSL streams for Tokio backed by BoringSSL
-
futures-util-io-peek
AsyncPeek trait
-
qiniu-apis
Qiniu HTTP APIs for Rust
-
shadocal
A blazingly fast, Google calendar (more in future) event formatter webserver tool
-
txn
A generic optimistic transaction manger, which is ACID, concurrent with SSI (Serializable Snapshot Isolation)
-
tarpc-example-service
An example server built on tarpc
-
deadpool-bolt
A bolt-client manager for the deadpool connection pool
-
fs4
No libc, pure Rust cross-platform file locks. Original fs2, now supports async and replace libc by rustix.
-
gain-lep
Support for exposing Gain APIs via Lep
-
unsync
Unsynchronized synchronization primitives for async Rust
-
openssh-sftp-client
Highlevel API used to communicate with openssh sftp server
-
dencode
decoding and encoding frames from readers and writers
-
stream_router
A Future aware router to dynamically route between Streams and Sinks
-
repsheet_etl
ETL tools for repsheet
-
mio-timerfd
mio support for linux's timerfd
-
async-spawner
executor independent task spawner
-
bawawa
Opinionated set of tools to manage and compose process executions
-
async-middleware
async monad(ish) middleware in Rust using tuples and async trait transforms
-
oauth-lib
Asynchronous Rust library to deal with OAuth flows
-
tokio-linux-aio
Tokio bindings for Linux kernel AIO
-
accumulate-api
Lower-level API for interfacing with the Accumulate Protocol via JSON-RPC
-
futures-enum
#[derive(Future, Stream, Sink, AsyncRead, AsyncWrite, AsyncSeek, AsyncBufRead)] for enums
-
zino-http
HTTP requests and responses for zino
-
docker_engine_api
way to interact with the Docker Engine API
-
mqttc
client for the MQTT protocol
-
cute-async
Cute async utilities
-
async-io-mini
Async I/O fork for embedded systems
-
bongonet-rustls
RusTLS async APIs for Bongonet
-
stream-map-any
Allows merging async Streams of different output type
-
radix-router
Rust port of httprouter
-
async-drop-guard
offers hash map and cache data structures where individual entries can be locked
-
tokio-blocking
A thin wrapper to provide a simple interface to insert blocking operations between non-blocking operations in the context of futures
-
tk-bufstream
A buffered stream backed by contiguous buffers (netbuf) for tokio
-
interprocess
communication toolkit
-
felixs-tower-lsp
Language Server Protocol implementation based on Tower
-
awesome-operates
A reposity includs many common use code utils
-
ora-api
Part of the Ora scheduler framework
-
diny
An asynchronous, alloc-free serialization framework
-
monoio-rustls-fork-shadow-tls
Asynchronous TLS streams wrapper for Monoio based on Rustls
-
obeli-sk-deps-async-sqlite
Fork of async-sqlite
-
woven
set of async combinators, usable in a no_std environment
-
usb-disk-probe
stream type which can be used to probe for USB storage devices in the system
-
path-tree
lightweight high performance HTTP request router for Rust
-
axum-messages
🛎️ One-time notification messages for Axum
-
holidayapi_rust
A HolidayAPI library for Rust
-
wait_not_await
awaiter implementation
-
ruspiro-channel
Bare Metal Channel implementations for
no-std
environments, only requiring an allocator to be provided -
async-ops
Use std::ops traits with Futures
-
ex-futures
An extension of
futures
-
actix-raft
Raft distributed consensus protocol using the Actix actor framework
-
reqwest-retry-after
Retry-After header support for reqwest
-
async-dup
Duplicate an async I/O handle
-
async-http1-lite
Asynchronous http1 stream
-
doh-proxy
A DNS-over-HTTPS (DoH) and ODoH (Oblivious DoH) proxy
-
auto-future
For quickly making a struct into a future via an async fn
-
yield-now
Wakes current task and returns Poll::Pending once
-
async-slot
An asynchronous (futures-based) channel that only preserves last value sent
-
toy-rpc-ha421
An async RPC that mimics golang net/rpc's usage and supports both async-std and tokio
-
axum-serveplus
High level server designed to be used with axum framework
-
bufstream
Buffered I/O for streams where each read/write half is separately buffered
-
salvo-serde-util
serde util for salvo
-
bp3d-net
Network utilities
-
async-fetcher
Asynchronous multi-connection multi-download resumable HTTP file fetching state machine
-
agnostic-lite
agnostic-lite
is an agnostic abstraction layer for any async runtime -
safina-select
Safe async select function, for awaiting multiple futures - ARCHIVED: Code moved to
safina
crate -
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
-
yacme-test
ACME test helpers for YACME
-
variable-len-reader
reading/writing variable length data. Support AsyncRead/AsyncWrite in tokio.
-
event_handlers
A unified library for handling events
-
retry_async
retrying, with specific support for the Azure SDK for Rust (cf. https://github.com/Azure/azure-sdk-for-rust).
-
asynchronous
Promises Q style , async and event loops
-
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. -
actix-async-await
Experimental async/await support for Actix
-
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
-
tiny_future
Condvar
based future with automatic cancellation on drop -
tower-pipeline
A Tower Service combinator that "pipelines" two services
-
bottle
Actor model framework for Rust
-
tokio-stdin
Read from stdin as a Tokio stream
-
dialectic-compiler
Session type macro compiler for the Dialectic crate
-
rustls-acme
TLS certificate management and serving using rustls
-
destream
async stream (de)serialization
-
graphile_worker_task_handler
handle tasks for the Graphile Worker project
-
tokio-extra-macros
Extra proc macros for Tokio
-
minicoro-sys
rust binding to minicoro
-
futurify
Convert your sync functions into non-blocking thread futures
-
unisock
Unified socket with different implementations
-
cucumber
testing framework for Rust, with async support. Fully native, no external test runners or dependencies.
-
alopecosa
Pure rust async Tarantool 1.6+ connector built on tokio
-
async-component-winit
winit async-component wrapper
-
ockam_node
Ockam [Ockam][main-ockam-crate-link] Node and is intended for use by crates that provide features and add-ons to the main [Ockam][main-ockam-crate-link] library. The main [Ockam][main-ockam-crate-link]…
-
futures-quic
quic protocol backed by Quiche
-
compio-tls
TLS adaptor with compio
-
xo-api-client
Unofficial crate for accessing Xen Orchestra through its API
-
pipebuf_rustls
PipeBuf wrapper for Rustls
-
aggligator-wrapper-tls
Aggligator transport wrapper: TLS
-
elfo-dumper
Dumps messages of the elfo system on disk
-
rust-gpt
interaction with the Completion/Chat OpenAI API
-
mutex-extra
RefMutex<T>
that is similar toMutex<T>
but isSync
andSend
even ifT
isn’tSend
-
ws-lite
Naive websocket server implemented using async / await
-
futures-jsonrpc
Futures implementation for JSON-RPC
-
gnostr-core
Replication protocol for Hypercore feeds
-
async-rx
functions for async reactive programming
-
d3
A framework for server development
-
rabble
creating location transparent actor based systems
-
ockam_app_lib
Ockam's desktop application library
-
async-graphql-derive
Macros for async-graphql
-
agnostik
Executor Agnostic Runtime that can run your futures with your favourite Executor
-
ferris_chats_server
This binary provides a server for ferris_chat
-
skrillax-stream
Combines skrillax-network crates to work nicely on top of a tokio tcp stream
-
again
wasm-compatible retry util for std library futures
-
streaming-platform
Data streaming platform and message broker with concurrent data transfer capabilities
-
kompact-actor-derive
A derive macro for Kompact Actors
-
seal_rs
Set of classic asynchronous primitives (Actors, Executors, Futures / Promises)
-
request-channel
Async MPSC request-reponse channel
-
brb
Byzantine Fault Tolerant (BFT) system for achieving network agreement over eventually consistent data-type algorithms such as CRDTs
-
tokio-resource-pool
A generic resource pool for the Tokio ecosystem
-
remcached
Caching system designed for efficient storage and retrieval of entities from remote repositories (REST APIs, Database, ...etc)
-
rexecutor-sqlx
A robust job processing library
-
actor
Actors traits
-
ctrlc2
Easy Ctrl-C handler version 2 for Rust projects
-
cortex-sources
Ready-made source implementations for various data inputs in the Cortex ecosystem
-
cqrs-core
Core types and traits for cqrs
-
see-you-later
Delay and schedule async task
-
foxhole-api
wrapper for the Foxhole War API
-
springtime-migrate-refinery
SQL migration framework based on dependency injection
-
background-jobs-core
Core types for implementing an asynchronous jobs processor
-
qudp
High-performance UDP encapsulation for QUIC
-
tokio-udp-framed
Based on UdpFramed from tokio-util but with some quality of life modifications to support shared ownership of
UdpSocket
and to split Send/Recv into their own types -
rs-firebase-admin-sdk
Firebase Admin SDK for Rust
-
speed-rs-core
A core HTTP handling server library in Rust, providing low-level HTTP server implementation
-
ockam_transport_ble
Bluetooth Low Energy (BLE) Transport for the Ockam Routing Protocol
-
libsync
containing channels and other synchronisation object implementations
-
strife
A lightweight library for the Discord API
-
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.
-
multipart-rfc7578
multipart/form-data (RFC7578)
-
gj
Event loop and promises
-
catalyzer-utils
development easier
-
mio-misc
Miscellaneous components for use with Mio
-
event_store
deal with every aspect of an eventstore
-
hyper-trust-dns-connector
A compatibility crate to use hickory-dns asynchronously with hyper client, instead the default dns threadpool
-
waitlist
Keep track of an ordered list of Wakers to wake
-
logic-mesh
Control logic engine using event based and reactive blocks written in Rust
-
tls-async
TLS support for AsyncRead/AsyncWrite using native-tls
-
postgres_rustls
TLS support for tokio-postgres via tokio-rustls
-
proc-heim
running and managing short-lived and long-lived processes using asynchronous API
-
memphis-rust-community
Memphis Messaging Protocol
-
tower-async-hyper
Bridges a
tower-async
Service
to be used within ahyper
(1.x) environment -
swiftide-docker-executor
A docker executor for swiftide agent tools
-
roundabout
An message oriented concurrent runtime
-
crb-system
CRB | Composable Runtime Blocks | System Integration
-
tokio-shared-rt
Allow
#[tokio::test]
to use a shared runtime -
retry_fn
retry function with versions for blocking or non-blocking, tokio or async-std
-
signals
A functional-reactive-like library for Rust that allows asynchronous chaining
-
futures-mockstream
Minimal mockstream which implements futures async traits
-
futuredsp
A signal processing library for SDR and real-time DSP
-
posturn
Build turn-based games with
async
Rust -
sqlxmq
A reliable job queue using PostgreSQL as a backing store
-
inklings
A unified Rust API for various Large Language Model (LLM) providers
-
unix-udp-sock
async & sync UDP sockets supporting sendmsg/recvmsg and src IP manipulation
-
async-graphql-parser
GraphQL query parser for async-graphql
-
tokio-lk
Futures-aware lock-by-id primitives
-
rxqlite-common
A distributed sqlite database built upon
openraft
,sqlx
andsqlite
-
trovo
A trovo.live api & chat client written in and for rust
-
futures-websocket
A futures-based websocket implementation
-
rseip-eip
encapsulation protocol for rseip
-
tower-sessions-dynamodb-store
AWS DynamoDB session store. Not for direct use; see the
tower-sessions
crate for details. -
miku-server-timing
An axum layer to inject the Server-Timing HTTP header into the response
-
samotop
SMTP server and library built on async-std
-
mezzenger-channel
mezzenger transport over futures channels
-
tower-async-http
Tower Async middleware and utilities for HTTP clients and servers. An "Async Trait" fork from the original Tower Library
-
qrecovery
The reliable transport part of QUIC, a part of gm-quic
-
intervalier
Interval events with handling notifications
-
tower-util
working with
Service
-
async-openai-types
OpenAI
-
must-done
An experimental Future that is guaranteed to be done
-
compio-signal
Signal handling for compio
-
completeio
Completion based IO drivers and async runtime
-
bluer
official Rust interface to the Linux Bluetooth protocol stack (BlueZ)
-
tower-reqwest
Adapter between reqwest and tower-http crates
-
black-box
A minimal actor framework
-
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) -
fut-compat
Offers compatibility between the tokio and async_std runtimes
-
twilight-http
Discord REST API client for the Twilight ecosystem
-
yaaf
Actor Framework
-
aster-proxy
A light, fast and powerful cache proxy written in Rust
-
viz-test
The core traits and types in for Viz
-
workflow-async-trait
Type erasure for async trait methods (customized, see README.md notes)
-
hyper-serve
High level server designed to be used with axum framework
-
apcacli
A command line tool for trading stocks on Alpaca (alpaca.markets)
-
channels-io
Async agnostic/Sync IO & buffer management abstractions
-
comet-eventbus
strong-typed sync and asynchronous eventbus
-
noosphere-core
Core data types of the Rust Noosphere implementation
-
gwyh
sweet gossip library
-
tokio-io-compat
Compatibility wrapper around std io traits that implements tokio io traits
-
tokio-timerfd
timerfd support for tokio
-
tower-sessions-sqlx-store
SQLx session stores for
tower-sessions
-
drop-awaiter
that allows you to asynchronously wait for something to be dropped
-
v_exchanges_api_generics
A client for HTTP/HTTPS/WebSocket APIs
-
timer-rs
timer used to schedule execution of closures at a given timestamp
-
async-stream-tls-upgrader
Asynchronous stream tls upgrader
-
ded
Dead Easy Deduplication
-
thetvdb
API async client
-
volo
high-performance and strong-extensibility Rust RPC framework that helps developers build microservices
-
puddle
object pool implementation that uses asynchronous synchronization primitives only
-
viz-handlers
The handlers for Viz
-
shutdown-async
Asynchronous Shutdown
-
awaitable-error
Awaitable type with input and output that can be stored in container
-
wasmflow-traits
encapsulating the message packets sent across Wasmflow components
-
peermerge
Manage JSON-like documents with multiple writers, without a central authority, using a P2P protocol
-
async-pidfd
Process file descriptors (pidfd) for Linux
-
rocket-session-store
session library that can use a custom store
-
atticus
A mimimal API to create asynchronous actors
-
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.
-
hyper_lua_actor
Binding of lua_actor & hyper
-
misskey-util
High-level API for the misskey-rs library
-
tourniquet-celery
Async native round-robin manager for remote services. celery integration.
-
dioxus-query
Fully-typed, async, reusable cached state management for Dioxus 🧬
-
async-graphql-extension-apollo-tracing
An async_graphql extension to send traces & metrics to Apollo Studio
-
cache-compute
implements request/async computation coalescing
-
async-debug
Debug structs and enums containing values that require an async call to render
-
libp2p-yamux
Yamux multiplexing protocol for libp2p
-
rust-moysklad
Framework for moy sklad
-
calloop
A callback-based event loop
-
mogwai
The minimal, obvious, graphical, widget application interface
-
extreme
Extremely boring async function runner. MIT/Apache-2.0 license is available for spacejam's github sponsors.
-
herbert
actor management
-
riker-deadletter
A Dead Letters logger for Riker
-
ruw
Read-Update-Write
-
extern_executor
Async executor which delegates futures polling to external event-loop
-
batch
Distributed task queue library based on RabbitMQ
-
vkteams-bot
VK Teams Bot API client
-
odem-rs-meta
Language extensions for the ODEM-rs simulation framework
-
heim-disk
Cross-platform disk information
-
prodash
A dashboard for visualizing progress of asynchronous and possibly blocking tasks
-
stream-future
Implement an async iterator with return value
-
intersession-layer-messaging
A metastable messenger that allows reliability between peers when peers go offline, are unreliable, and facing intermittent network conditions between sessions
-
windows-async
async executor for windows application using windows crate
-
sendblue
that provides an API client for interacting with the SendBlue REST API, enabling businesses to integrate iMessage and SMS services into their applications
-
compio-dispatcher
Multithreading dispatcher for compio
-
mobc-forked
A generic connection pool with async/await support
-
ctrlc-async
Easy asynchronous Ctrl-C handler for Rust projects
-
lazy-queue
Futures-driven lazy queue processing
-
form-data
AsyncRead/AsyncWrite/Stream
multipart/form-data
-
wtr-watcher
Filesystem watcher. Works anywhere. Simple, efficient and friendly.
-
futures-option
Extension traits for dealing with optional futures and streams
-
suspend-channel
Channel and stream implementations
-
deepwell
Wikijump API provider and database manager
-
callback-future
Adapter between callbacks and futures
-
tower-http
Tower middleware and utilities for HTTP clients and servers
-
streamify
Conversions from values to Stream
-
tmpdir
Useful to create temp directories and copy their contents on completion of some action. Tmp dirs will be created using [
env::temp_dir
] with some random characters prefixed to prevent a name clash -
irc
usable, async IRC for Rust
-
actix-server
General purpose TCP server built for the Actix ecosystem
-
arta
Async runtime abstractions library
-
actix-taskqueue
A generic task queue service for Actix
-
cdrs-tokio
Async Cassandra DB driver written in Rust
-
cargo-daku
Daku API cargo plugin
-
ruyi
An event-driven framework for non-blocking, asynchronous I/O in Rust
-
tokio-macros
Tokio's proc macros
-
specta-util
High-level utilities for working with Specta
-
await_macros
Macros that expand to
(expr).await
-
async_zip
An asynchronous ZIP archive reading/writing crate
-
connman
that abstracts the D-Bus layer
-
heim-process
Cross-platform processes information
-
simple-scheduler
Schedule periodic tasks to run asynchronously
-
qcow2-rs
read/write qcow2 image in async/await
-
fil_actors_runtime_v8
System actors for the Filecoin protocol
-
tower-async-test
writing client and server
Service
tests. An “Async Trait” spiritual fork from the original tower-test Library -
gneiss-mqtt-aws
AWS IoT Core specific builders for asynchronous and threaded MQTT clients
-
nbchan
Highly optimized non-blocking communication channels
-
jarust_rt
A janus client SDK in Rust
-
openssh-sftp-protocol-error
Data format used to communicate with openssh mux server
-
nb
Minimal non-blocking I/O layer
-
future_handles
complete futures via handles
-
peace_flow_model
Flow data model for the peace automation framework
-
stalk
sending serialized data with tokio
-
axum-prometheus
A tower middleware to collect and export HTTP metrics for Axum
-
futures-async-runtime-preview
Runtime for the async/await macros in the
futures
crate -
tor-rpc-connect
Common implementation logic for Arti RPC Connect points
-
peace_cmd
Command structure for the Peace framework
-
uasync
fast, safe, async executor
-
papaleguas
ACME client
-
epics-ca
Client library for EPICS Channel Access protocol
-
netsim
Run tests in network-isolated threads. Intercept and meddle with their packets.
-
eventually
using Event Sourcing in Rust applications
-
tauri-wasm
The tauri framework library for pure rust frontend
-
batched-fn
Middleware for serving deep learning models with batched prediction
-
squinn
Versatile QUIC transport protocol implementation with SCION support
-
tarpc-bincode-transport
A bincode-based transport for tarpc services
-
mfio-netfs
mfio based network filesystem
-
rlg
that implements application-level logging with a simple, readable output format. Features include log rotation, network logging, and support for multiple structured formats like JSON, CEF, and more.
-
igdb
Video Game Database Api
-
monoio-io-wrapper
A read/write wrapper to bridge sync and async io
-
luarmor
API wrapper for luarmor.net
-
spmc-logger
A single-producer multi-consumer persistent logger
-
zino-auth
Authentication and authorization for zino
-
tracing-layer-slack
Send filtered tracing events to Slack
-
async-raft2
An async implementation of the Raft distributed consensus protocol
-
ratchet_rs
Async WebSocket implementation
-
openraft-rocksstore-compat07
A example v07 compatible implementation of the
openraft::RaftStorage
trait -
local-pool-with-id
A minor variation on a LocalPool executor which exposes unique IDs for tracking future completion
-
socks5-proxy
socks5 library based on tokio offering both server and client functions
-
futures-timer
Timeouts for futures
-
deli
ergonomic way to define data models that are seamlessly converted into IndexedDB object stores, utilizing derive macros
-
mobc-bolt
A bolt-client manager for the mobc connection pool
-
batch-renamer
Framework and command line utilities for interactive renaming of a potentially large number of files
-
waitfor
Retry a function until it succeeds, errors out, or a timeout/deadline is reached
-
garcon
A collection of trait and classes to make your thread or async function wait
-
tracing-forest
Preserving contextual coherence among trace data from concurrent tasks
-
tower-sessions-deadpool-sqlite-store
deadpool-sqlite session store for
tower-sessions
-
spawns
Async runtime agnostic thread context task spawner for Rust
-
vmc
Virtual Motion Capture protocol for virtual avatar tracking
-
rusher
Pusher compatible pubsub service
-
puppet
actor framework which uses no dynamic dispatch or boxing
-
moosicbox_task
MoosicBox task utilities package
-
kapacitor-multi-indicator-batch-udf
A multi-indicator batch UDF for Kapacitor
-
tower-sessions-surrealdb-store
SurrealDB session store. Not for direct use; see the
tower-sessions
crate for details. -
rama-haproxy
rama HaProxy support
-
bytes-stream
functions to work with stream of bytes
-
futures-shuttle
Futures-aware shuttle synchronization object
-
weaviate-community
Community client for handling Weaviate vector database transactions written in Rust, for Rust
-
async-stream-http-tunnel-grader
Asynchronous stream http tunnel grader
-
tokio-utils
Tools for asynchronous programming in Tokio applications
-
pipebuf_mio
PipeBuf support for
mio
byte-streams -
flysystem
A filesystem abstraction layer for Rust
-
axum-server
High level server designed to be used with axum framework
-
cloudwatch_logging
logging to AWS CloudWatch Logs
-
tokio-non-async
Helpers for dealing with tokio channels in non-async code
-
lspower
A lightweight framework for implementing LSP servers
-
duplexify
Combine a reader + writer into a duplex of Read + Write
-
async-graphql-viz
async-graphql for viz
-
async-shell
Asynchronous process child wait
-
stream-reduce
Fold a stream without an initial value
-
zino-storage
Files and storage services for zino
-
futures-stable-preview
futures which support internal references
-
pick_action_from_image
Pick an action from an image
-
multiparty
zero copy streaming multipart decoder implementation
-
prefect
An embeddable task queue based on SQLite (renamed to effectum)
-
sendfile
wrapper around the sendfile(2) system call
-
greenthread-future
Convert closures to futures based on greenthread on bare-metal (no_std + no_alloc)
-
tonic-middleware
Async middleware and interceptor for Tonic services
-
toni-macros
Macros for Toni
-
iroh-quinn
Versatile QUIC transport protocol implementation
-
smartpoll
A 'Task' abstraction that simplifies polling futures
-
futures-to-stream
Turn heterogeneous Futures of same associated Output type to a stream
-
simple-async-local-executor
A single-threaded polling-based executor suitable for use in games, embedded systems or WASM
-
stream-utils
Additional stream combinators
-
kayrx
Framework
-
async-component
Zero overhead reactive programming
-
peace_params
Constraints and specifications for parameters for the peace automation framework
-
async-llm
OpenAI-compatible APIs
-
elfo-network
Distributed actors for elfo
-
fil_actors_runtime_v11
System actors for the Filecoin protocol
-
anansi-aux
Anansi's auxiliary library
-
tokio-futures-respawn
function to respawn failed long running tasks
-
hreq-h2
An HTTP/2.0 client and server
-
jackrabbit
Real-time Message Queue
-
abstract-ns
Abstract name service traits for use with futures (and tokio)
-
ironmq-client
IromMQ client library (AMQP 0.9)
-
stick
Platform-agnostic asynchronous gamepad, joystick and flighstick library
-
smol-hyper
Integrations between smol and hyper
-
uid-mux
Async multiplexing library with user provided stream ids
-
patchable-async-sleep
An async sleep function, patchable to the preferred runtime
-
spotify-rs
wrapper for the Spotify API
-
aktrs
An actor model framework for Rust
-
actix-utils
Various utilities used in the Actix ecosystem
-
nonblocking
stdin crate for Rust
-
unsend
A thread unsafe runtime for thread unsafe people
-
async-global-executor-trait
executor-trait implementation for async-global-executor
-
posixmq
An idiomatic library for using posix message queues, with optional mio integration
-
asteroid-mq-sdk
Rust SDK for asteroid-mq
-
dummy-waker
Get a
core::task::Waker
that does absolutely nothing -
tokio-buf
Asynchronous stream of byte buffers
-
agreed-memstore
An in-memory implementation of the
agreed::RaftStorage
trait. Fork of async-raft’s memstore crate. -
sigfinn
Lifecycle manager for spawning tasks
-
citadel_sdk
High-level library to build applications on the Citadel Protocol
-
manual-executor
Async executor with manual waking
-
rdma
Low-level RDMA API
-
simple-async-pipe
Aims to provide a simple pipe-like functionality for async code
-
izihawa-hyper-multipart
multipart/form-data for Hyper
-
async-graphql-axum-wasi
async-graphql for axum
-
peace-performance
osu! pp & stars calculation. Peace edition
-
mysql_async_uu
Tokio based asynchronous MySql client library
-
completion
writing completion-based asynchronous code
-
vru-cancel
Cancel tokio stream
-
npm-package
client for fetching metadata from the npm package
-
orengine-macros
Procedural macros for use with Orengine
-
mqtt-channel-client
MQTT client that communicates over Tokio channels
-
async-option
Essentially an asynchronous Async<Mutex<Option<T>>>
-
jsonrpc-rs
Futures base jsonrpc server/client framework
-
uring-fs
Truly asynchronous file operations using io-uring. Supports any async runtime. Linux only.
-
compio-process
Processes for compio
-
async-timer
Timers for Rust async story
-
leaves
Distributed ID Allocator
-
stream_multiplexer
Combines many streams into a few
-
tokio-serde
Send and receive Serde encodable types over the network using Tokio. This library is used as a building block for serialization format specific libraries
-
anthropic
SDK
-
diath
light-weight library for communication between tokio async tasks
-
psbus
Generic Publish / Subscribe model for application messaging
-
async-priority-queue
An async-aware priority queue
-
kiteticker-async
Async version of the ticker module of the kiteconnect-rs crate
-
async-subscription-map
Async bookkeeping datastructure for state subscriptions
-
qunreliable
Unreliable transmission of gm-quic
-
scrappy_do
A concurrent asynchronous webscraping framework
-
lstngrp
Groups listeners and connections with common data/logic
-
async-attributes
Experimental language-level polyfills for Async Rust
-
axum-limit
A rate limiting library using token buckets, centered around extractor-based limits for async web applications
-
marzban_api
async client which abstracts/simplifies the interactions with the Marzban panel API (https://github.com/Gozargah/Marzban)
-
june
ergonomic remote actors via actix and canary
-
futures-rustls
Asynchronous TLS/SSL streams for futures using Rustls
-
linux-io-uring-sys
The
io_uring
bindings for Rust -
async-gigachat
Async bindings for Gigachat API
-
async-core
A standard for async runtimes
-
mt_logger
A low-dependency, multithreaded logging library with a focus on traceability and ease-of-use via macros
-
aredis
Redis client implemented in Rust
-
agnostic-io
agnostic-io
defines I/O traits in agnostic style for any async runtime -
gloo-timers
Convenience crate for working with JavaScript timers
-
mwmr
A generic optimistic transaction manger, which is ACID, concurrent with SSI (Serializable Snapshot Isolation)
-
juniper
GraphQL server library
-
noop-waker
A waker that does nothing
-
futures-stream-select-ext
futures::stream::select Ext
-
axum-macros
Macros for axum
-
aldrin
Message bus for service-oriented RPC and interprocess communication
-
serf
A decentralized solution for service discovery and orchestration that is lightweight, highly available, and fault tolerant
-
async-cuda-core
Async CUDA streams and buffers for Rust
-
num_stream
that provides a Stream that yields incrementing numbers at a specified interval
-
pagetop
Un entorno de desarrollo para crear soluciones web modulares, extensibles y configurables
-
async_main
Runtime-agnostic async main proc macro
-
cloudflare-workers-kv-sdk-rs
Unofficial Cloudflare Workers KV SDK for Rust-Lang
-
tokio-beanstalkd
Asynchronous client library for interacting with Beanstalkd work queue
-
redis-asio
Asynchronous Redis driver based on tokio
-
manual_future
A future that must be manually completed, similar to Java's CompletableFuture
-
twitchchat
interface to the irc-side of twitch's chat system
-
freestuffapi
Freestuffbot API
-
ya-etcd-rs
etcd client for rust
-
asbru
A Data-oriented service mesh generator
-
ruchei-callback
Callback traits for ruchei
-
async-stdin
Asynchronously read from stdin
-
chtsh
Rust CLI for interacting with https://cht.sh
-
salvia
Incremental computing brought to async Rust
-
cyper-axum
axum adaptor based on cyper
-
aector
Dynamic implementation of the actor model with a smart built-in testing framework
-
fibers_transport
Transport layer abstraction built on top of [
fibers
] crate -
rumeter-component
A load test platform for writing a load test script by rust. Just like JMeter, but it prefer using like SDK, not a GUI tool
-
hala-future
hala asynchronous programming primitive types
-
mio-byte-fifo
Concurrent non-blocking byte SPSC FIFO buffer intended for use in Mio poll
-
requiem-testing
Actix testing utils
-
openssh-mux-client
openssh mux client
-
zephyrus-macros
Procedural macros used by Zephyrus
-
async-reactor-trait
reactor-trait implementation for async-io
-
folo
Runtime engine for Rust services
-
madsim-macros
Madsim's proc-macro
-
groq-api-rs
Client For Groq Cloud LLM APIs
-
verypoll
Very polling library
-
noosphere-fs
A high-level, FS-like view over Noosphere content
-
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.
-
salvo-oapi
OpenApi support for Salvo web framework
-
framed_aio
allows performing async io operations in a framed manner
-
untokio
Automatically create tokio runtimes
-
signalr-client
calling SignalR hubs from a Rust cross-platform application, supporting WASM and non WASM targets
-
stage
An ergonomic, composable Actor Model, designed for painless concurrency
-
simple-async
Very simple async runtime for Rust
-
gen-z
Macro-free stream construction through asynchronous generators via an awaitable sender
-
hapic
HTTP API Client (hapic): A Rust crate for quickly creating nice-to-use client libraries for HTTP APIs, in particular, there's lots of tooling around HTTP JSON APIs
-
hitbox
Asynchronous caching framework in Rust
-
destream_json
decoding & encoding a JSON stream
-
barrage
An async broadcast channel
-
ntex-grpc
GRPC Client/Server framework
-
hyper-http-proxy
A proxy connector for Hyper-based applications
-
tauri-plugin-rspc
Tauri adapter for rspc
-
awaur
Asynchronous Web API Utilities for Rust
-
naumi
Lightweight and fast data transfer protocol. Fast de/serialization and tiny size!
-
kabuki
Name reservation
-
tokio-channel
Channels for asynchronous communication using Tokio
-
nb-executor
Single-future, #![no_std] executor based on event bitmasks
-
yash-executor
single-threaded concurrent task executor
-
tokio-byteorder
Asynchronous library for reading/writing numbers in big-endian and little-endian
-
routerify
A lightweight, idiomatic, composable and modular router implementation with middleware support for the Rust HTTP library hyper.rs
-
polaris-core
Lightweight Rust SDK used as Proxyless Service Governance
-
st7735-async-low
Low-level async library for 4-wire serial ST7735
-
tacacs-plus
An asynchronous, runtime-independent RFC8907 TACACS+ client
-
dmm-api
DMM Web API SDK
-
tinywake
A minimal, no_std-compatible waker implementation for Cortex-M async executors
-
wtransport
WebTransport (over HTTP3) protocol
-
kyansel
Cancellable future. Provide a future as argument and the current future will cancel if the provided future resolves first
-
heim-virt
Cross-platform virtualization system detection
-
ruarango
ArangoDB Client Implementation
-
rusty-gql
Schema first GraphQL Library for Rust
-
tarpc-lib
An RPC framework for Rust with a focus on ease of use
-
smol-macros
Macros for setting up a smol runtime
-
v_rusty_tarantool
Tarantul async client based on tokio framework
-
connection
A TCP connection that can read and write serializable data
-
implicit-await
Implicitly await calls returning Future impls
-
tracing-appender
file appenders and making non-blocking writers
-
embassy-executor
async/await executor designed for embedded usage
-
elfo-pinger
Pings groups of the elfo system
-
fizyr-rpc
Native Rust implementation of the Fizyr RPC protocol
-
viz-core
The core traits and types in for Viz
-
tcp-stream
std::net::TcpStream on steroids
-
mlg
An asynchronous Log for Rust
-
tower-sessions-sqlx-store-chrono
SQLx session stores for
tower-sessions
but usingchrono
instead oftime
-
throttled-reader
An io::Read proxy that limits calls to read()
-
jarust_interface
A janus client SDK in Rust
-
futuresdr-types
Polymorphic Types for an Experimental Async SDR Runtime for Heterogeneous Architectures
-
ipc-orchestrator
Orchestion of command line processes for local dev usage with IPC communication
-
madsim-etcd-client
The etcd simulator on madsim
-
rivulet
Asynchronous contiguous-memory streams
-
embedded-hal-async
An asynchronous Hardware Abstraction Layer (HAL) for embedded systems
-
suspend_fn
macro for implicit await
-
tokio-lock
Access an object from a single Tokio task
-
citadel_logging
logging library for the Citadel Protocol
-
syncthing
controlling syncthing file synchronization through its REST interface
-
tokio-iocp
IOCP support for the Tokio asynchronous runtime
-
future_pubsub
A tokio based publish-subscibe channel
-
futures-stream-reader
Convert an [AsyncRead] into a [Stream] of byte chunks
-
catty
Send and await a value asynchronously
-
libp2p-identify
Nodes identification protocol for libp2p
-
rust_transit
A broker-agnostic asynchronous event library
-
json-array-stream
Incrementally reads a JSON array through an async stream
-
mias_channel
that supports bi-directional channels by wrapping others
-
tokio-anon-pipe
Asynchronous anonymous pipe for Windows
-
heim-net
Cross-platform network information
-
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
-
monolake
High Performance Proxy base on Monoio
-
alligator
getting the output value from a future
-
whorl
was created to teach you how async executors work in Rust
-
bb8_surrealdb2
Surrealdb support for the async bb8 connection pool
-
txrx
take on the C++ unified executors proposal
-
hop
Rust client library for the Api
-
actix-test-server
Actix test server
-
rseip-core
core module for rseip
-
async-watch
Async watch channel
-
rusty-penguin
A fast TCP/UDP tunnel, transported over HTTP WebSocket
-
thalo_runtime
A high-performance event sourcing runtime utilizing WebAssembly an embedded event store
-
async_io_crypto
handling AsyncRead with ciphering / deciphering
-
switchyard
Real-time compute focused async executor
-
holly
A simplistic actor model library using futures
-
ianaio-timers
IanaIO crate for working with JavaScript timers
-
relay
A lightweight oneshot Future channel
-
zino-axum
Integrations with axum for zino
-
eventbuzz_core
The core submodule of eventbuzz project
-
async-rustls-stream
An async tls stream library based on rustls and futures-io. Both for server/client.
-
monoio-native-tls
Asynchronous TLS streams wrapper for Monoio based on NativeTLS
-
erkpht-tower
Tower is a library of modular and reusable components for building robust clients and servers
-
tokio-async-std
An async-std that can fit into tokio ecosystem straight ahead
-
light-magic
A lightweight, fast and easy-to-use implementation of a optionally encrypted/persistent in-memory database
-
nostr-bot
Nostr bot library
-
futures-length-delimited-frame
Frame a stream of bytes based on a length prefix
-
tower-limit
Limit maximum request rate to a
Service
-
futures-async-combinators
toy futures combinators
-
rustdtp
Cross-platform networking interfaces for Rust
-
rustmark
Extensible web application for serving Markdown-based content
-
pingora
A framework to build fast, reliable and programmable networked systems at Internet scale
-
tempest
Realtime message handling framework inspired by Apache Storm and built with Actix
-
delete
Fast, easy deletion of files and folders with async and cross-platform support
-
asyncore
-
msgtrans
Support for a variety of communication protocols such as TCP / QUIC / WebSocket, easy to create server and client network library
-
tower-etag-cache
A tower middleware for implementing ETag-based HTTP caching
-
coerce-rt
Async actor runtime
-
embassy-futures
no-std, no-alloc utilities for working with futures
-
ohkami
Build web app in intuitive and declarative code
-
fieldset
Struct to enum derivation
-
gidle_future
A future executor for the glib main loop idle time
-
mai
A higher-level mio interface
-
generic-api-client
A client for HTTP/HTTPS/WebSocket APIs
-
d3-components
A framework for server development -- the component layer
-
async-graphql-actix-web
async-graphql for actix-web
-
fsdr-blocks
Building blocks for FutureSDR signal processing library for SDR and real-time DSP
-
param
Param-style trait
-
gloo-file
Convenience crate for working with JavaScript files and blobs
-
async-http-client-lite
Asynchronous http client
-
spmc_buffer
An extension of triple buffering for multiple-consumer scenarios, useful for sharing frequently updated data between threads
-
tracing-actix-web2
Rust tracing adapter for Actix Web
-
beul
It executes futures
-
zino-openapi
OpenAPI support for zino
-
bbb_api_wrapper
A wrapper for BuiltByBit's Ultimate REST API
-
socks5-server
Fine-grained relatively low-level asynchronized SOCKS5 server library based on tokio
-
emitter-rs
📢 Emitter RS is a lightweight EventEmitter implementation for Rust and Wasm
-
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.
-
uller
Generate/Donwload your links
-
poller
File I/O events library for Rust
-
arti-bench
benchmarking utility for Arti
-
qconnection
Encapsulation of QUIC connections, a part of gm-quic
-
peace_cli_model
Command line interface data types for the peace automation framework
-
indexed-db
Bindings to IndexedDB that default the transactions to aborting and can work multi-threaded
-
crb-download
CRB | Composable Runtime Blocks | Downloader
-
waaa
WebAssembly, Abstracted Away
-
elfo-logger
Logs events of the elfo system
-
async-macros
Macros for async-std
-
tokio-compat-02
Tokio 0.2 compat utilities
-
coil
An async and sync background job queue for Postgres
-
stream-body
An HttpBody implementation with efficient streaming support for the Rust HTTP library hyper
-
create-rspc-app
Get started with your next rspc app!
-
nervemq
Portable, SQS-compatible message queue backed by SQLite
-
async-http-body
Agit init HttpBody Support Async Expressions
-
tower-buffer
Buffer requests before dispatching to a
Service
-
packet-ipc
Share packets between services using servo ipc
-
logged-stream
Logging of all read/write operations, errors and drop of underlying IO object
-
tower-sesh-core
Core components for
tower-sesh
and related crates -
ntex-grpc-codegen
GRPC Client/Server framework (codegen)
-
shave
shaving data from websites
-
surrealdb-async-graphql-axum
async-graphql for axum
-
bellande_mesh_sync
Advanced peer-to-peer data synchronization system for distributed applications
-
back-to-the-future
Conversions between std::future::Future and futures::Future
-
scambio
Safe and efficient value exchanges between endpoint pairs
-
hydro
cooperative green tasks
-
hyper-proxy
A proxy connector for Hyper-based applications
-
dialectic-tokio-mpsc
A backend for the Dialectic crate using Tokio's MPSC channels
-
mqtt-codec-kit
MQTT v3.1.1/v5.0 protocol async codec
-
async-rwlock
Async reader-writer lock
-
redeez
queueing system for Redis
-
skipdb-core
The core for
skipdb
andasync-skipdb
crates -
tower-worker
Tower layers focused on wrapping services with asynchronous worker tasks that may also make requests to the wrapped service
-
deadpool
Dead simple async pool
-
tinyio
A tiny Rust concurrency runtime library
-
async-std-test
Alternate implementation of the #[async_std::test] macro
-
peace_rt_model
Runtime data types for the peace automation framework
-
misanthropic
An async, ergonomic, client for Anthropic's Messages API
-
async-ioutils
A collection of async utilities for I/O
-
taskwait
Runtime agnostic way to wait for a group of async tasks
-
erl_dist
Erlang Distribution Protocol
-
twilight-lavalink
Lavalink client for the Twilight ecosystem
-
citadel_proto
Networking library for the Citadel Protocol
-
volo-thrift
Thrift RPC framework implementation of volo
-
plctag
wrapper of libplctag, with rust style APIs and useful extensions
-
rspc-tauri
Tauri adapter for rspc
-
openssh-sftp-error
Error type used when communicating with openssh sftp server
-
socks5-impl
Fundamental abstractions and async read / write functions for SOCKS5 protocol and Relatively low-level asynchronized SOCKS5 server implementation based on tokio
-
mioqu
queuing and processing background tasks
-
tower-sessions-redis-store
Redis session store for
tower-sessions
-
async-transport
Asynchronous transports with ECN information
-
alicemq
Wapper for the amqprs rabbitMQ library
-
crb-runtime
CRB | Composable Runtime Blocks | Runtime
-
aggligator-transport-tcp
Aggligator transport: TCP
-
idb-sys
A callback based crate for interacting with IndexedDB on browsers using webassembly
-
async-executor-trait
executor-trait implementation for async-std
-
wasm-agnostic
users who want to write async runtime-agnostic crate for wasm target
-
libp2p-swarm-test
Test framework for code building on top of libp2p-swarm
-
async-graphql-value
GraphQL value for async-graphql
-
async-compression
Adaptors between compression crates and Rust's modern asynchronous IO types
-
smol-timeout2
A way to poll a future until it or a timer completes
-
prk_async_dataflow
An asynchronous dataflow processing library for Rust with SIMD-accelerated JSON parsing and AI agent capabilities
-
nodecraft
Crafting seamless node operations for distributed systems, which provides foundational traits for node identification and address resolution
-
async-ioutil
A collection of Rust asynchronous I/O utilities
-
kcp-rs
KCP Stream Protocol
-
watchfile
An async utility trait to subscribe to file changes of a serializable file
-
vesper-macros
Procedural macros used by Zephyrus
-
motore-macros
Motore's proc macros
-
sockit
A UDP socket that can read and write serializable data
-
async-thread
Futures version of std::thread
-
etcd-rs
etcd client for rust
-
task-executor
A task executor
-
heph-rt
speciailised runtime for Heph's actor
-
async-graphql-axum
async-graphql for axum
-
ant-libp2p-swarm
The libp2p swarm
-
thespis_impl
Reference implementation for the thespis actor model
-
rustis
Redis async driver for Rust
-
futuresdr-pmt
Polymorphic Types for an Experimental Async SDR Runtime for Heterogeneous Architectures
-
tower-sessions-libsql-store
A small library for using tower-sessions with libsql
-
tiny-jsonrpc
Json rpc lib based on reqwest
-
citadel_crypt
Higher-level cryptographic library for the Citadel Protocol
-
hyena
async task pool
-
yacme-service
ACME high-level client library
-
tokio-uds-proto
Unix Domain sockets working with tokio-proto
-
architect-tonic-build
Codegen module of
tonic
gRPC implementation -
peace_webi_rt
Web interface runtime data types for the peace automation framework
-
signalfut
A future similar to tokio::signal::unix::Signal, but can be used with all the runtimes
-
eternal
Framework
-
crb-routine
CRB | Composable Runtime Blocks | Routine
-
async-ready
Async readiness traits
-
poem-grpc
GRPC support for Poem
-
openssh-mux-client-error
openssh mux client
-
xio
providing common functionality for file system operations and asynchronous file processing
-
ockam_executor
Ockam async executor crate
-
cassandra-protocol
Cassandra protocol implementation
-
delimiter-slice
Stream type for splitting a delimited stream
-
mirai
A Futures layer over Mio
-
kayrx-ui
Framework
-
tonic-reflection
Server Reflection module of
tonic
gRPC implementation -
gloo-worker
Convenience crate for working with Web Workers
-
yap2p
Experimental yet another peer-to-peer library
-
improv
Actor microframework
-
eventum
Asynchronous I/O Event manager
-
continue
Swift-style continuation API
-
wtransport-proto
WebTransport (over HTTP3) protocol
-
async-mongodb-session
An async-session implementation for MongoDB
-
maybe-async-channel
A channel which may or may not be async
-
ara
Async random access I/O traits
-
anthropic-sdk
Anthropic Rust SDK
-
holiday_event_api
The Official Holiday and Event API for Rust
-
tubetti
Serve &[u8] data at a localhost url with minimal configuration
-
peace_rt
Runtime logic for the peace automation library
-
asteroid-mq-model
Basic models for asteroid-mq
-
misskey-core
Core traits and types in misskey-rs
-
stabilityai
stability.ai library based on OpenAPI spec
-
memstore
An in-memory implementation of the
async-raft::RaftStorage
trait -
jarust_core
A janus client SDK in Rust
-
wamp_async
An asynchronous WAMP implementation
-
iroh-quinn-udp
UDP sockets with ECN information for the QUIC transport protocol
-
exo_task
A lightweight async task executor for bare metal (or any) systems
-
tokio-dbus-macros
Pure Rust D-Bus implementation for Tokio
-
rama-proxy
proxy types and utilities for rama
-
waaaa
WebAssembly, Abstracted Away
-
stream_generator
Allows to easily generate streams with async/await
-
quinn-proto
State machine for the QUIC transport protocol
-
lelet
golang like task executor
-
logimesh
RPC Microservice 2.0 framework
-
actix-service
Service trait and combinators for representing asynchronous request/response operations
-
multipart-rs
zero-allocation, streaming, async multipart reader & writer for Rust
-
async-openai-wasm
OpenAI on WASM
-
qbase
Core structure of the QUIC protocol, a part of gm-quic
-
async-graphql-poem
async-graphql for poem
-
genawaiter-macro
Convenience macros for generators (genawaiter)
-
ntex-async-std
async-std intergration for ntex framework
-
rdbc-rs
Futures base Rust DataBase Connectivity (RDBC) library
-
ratsio
client library for NATS messaging system and NATS Event Streaming
-
tokio-fd
Non-blocking Read and Write a Linux File Descriptor
-
runtime-loop
Runtime loop for Rust
-
axum-flash
Web framework that focuses on ergonomics and modularity
-
openssh-sftp-protocol
Data format used to communicate with openssh mux server
-
memberlist-types
Types used in the memberlist crate
-
basteh
Generic kv storage with replaceable backend
-
axum-tungstenite
WebSocket connections for axum directly using tungstenite
-
multitask
An executor for running async tasks
-
grpcio
language implementation of gRPC, base on the gRPC c core library
-
async-graphql-relay
Relay support for async-graphql
-
tokio-bincode
Bincode based
tokio-codec
adapter -
async-entry
extended Tokio's proc macros
-
associated-async-io
Async IO traits that use futures instead of poll
-
tor-events
A typed event broadcasting framework for Arti
-
ockam
End-to-end encryption and mutual authentication for distributed applications
-
zino-actix
Integrations with actix-web for zino
-
tower-batch
batch-tower
is a Tower middleware that allows you to buffer requests for batch processing until the buffer reaches a maximum size OR a maximum duration elapses -
lucia-apis
A set of API collections based on the lucia framework
-
async_channel_io
AsyncRead
andAsyncWrite
implementations forasync_channel
-
compio-log
Log of compio
-
message-io
Fast and easy-to-use event-driven network library
-
aggligator-transport-webusb
Aggligator transport: WebUSB for targeting WebAssembly
-
pychan
A collection of channels for sending around items of type
pyo3::Py<T>
-
hyper-proxy2
A proxy connector for Hyper-based applications
-
winit-runtime
Async winit runtime
-
pulz-executor
Abstractions of some async runtimes
-
completeq-rs
An alternative to passing messages between asynchronous tasks
-
crdb-server
Concurrently Replicated DataBase
-
axum-sessions
🥠 Cookie-based sessions for Axum via async-session
-
core-futures-tls
A libcore wrapper allowing async/await to be used from no_std crates
-
shuller
Lib to get links to images for your favourite tags on rule34 and any
-
anansi
full-stack web framework for Rust
-
pea2pea
low-level, and customizable implementation of a TCP P2P node
-
aldrin-broker
Broker library of Aldrin, a message bus for service-oriented RPC and interprocess communication
-
pangotls
TLS Reverse Proxy using Tokio and Rustls
-
peace_item_tar_x
Manages extracting a tar file for the peace framework
-
specta
Easily export your Rust types to other languages
-
plctag-async
async wrapper for libplctag
-
async-watch2
Async watch channel
-
daku
Interface to the Daku API
-
pingora-proxy
Pingora HTTP proxy APIs and traits
-
async-await
Just some macros to emulate the Async and Await :)
-
cyper-core
Core adaptors and services for compio running on hyper
-
futuresdr-frontend
Web Frontend for an Experimental Async SDR Runtime for Heterogeneous Architectures
-
liburing
Rust liburing#24bd087 raw bindings with basic tests
-
bongonet-openssl
OpenSSL async APIs for Bongonet
-
futures-macro-await-preview
Definition of the
await!
macro for thefutures
crate -
roa
async web framework inspired by koajs, lightweight but powerful
-
async-timer-rs
Hashed timer wheel implementation compatible with asynchronous tasks, support async_std/tokio and other futures base framework
-
async-imap-lite
Asynchronous imap
-
d3-core
A framework for server development -- the core layer
-
peace_webi
Web interface for the peace automation framework
-
async-openai-wasi
Async bindings for OpenAI REST API based on OpenAPI spec
-
alzheimer
Async implementation of brainfuck interpreter
-
rillrate-system
RillRate agent for system monitoring
-
tower-sessions-moka-store
Moka session store for
tower-sessions
-
async-process
Async interface for working with processes
-
rama-dns
DNS support for rama
-
juliex
a very basic future executor
-
libp2p-stream
Generic stream protocols for libp2p
-
tower-balance
Balance load across a set of uniform services
-
yaar
asynchronous runtime optimized around configuration and no_std
-
ssdp-client
An asynchronous library for discovering, notifying and subscribing to devices and services on a network
-
socketioxide
Socket IO server implementation in rust as a Tower Service
-
async-barrier
An async barrier
-
pavex
A framework for building API services and web applications in Rust
-
agnostic-dns
agnostic-dns
is an agnostic abstraction layer overhickory-dns
-
crdb-cache
Concurrently Replicated DataBase
-
gerevs
implementing general-purpose SOCKS5 proxy servers with asynchronous execution and flexible authentication methods
-
crb-morph
CRB | Composable Runtime Blocks | Morph
-
requiem-threadpool
Actix thread pool for sync code
-
tower-sessions-file-based-store
File-based session store for
tower-sessions
-
crud_hyper
CRUD (Create, Read, Update, Delete) web application built using Rust’s
hyper
library. This project demonstrates how to implement basic CRUD operations with an in-memory database and… -
aral-runtime-async-std
Aral Runtime for async-std
-
handy_io
A handy pattern and futures based asynchronous I/O library
-
sse-stream
Convert a http body into sse stream
-
ohkami_openapi
OpenAPI types for Ohkami - intuitive and declarative web framework
-
mpool
A generic connection pool
-
tonic-health
Health Checking module of
tonic
gRPC implementation -
clia-ntex-files
Static files support for ntex web
-
ant-libp2p-swarm-test
Test framework for code building on top of libp2p-swarm
-
futures-test-sink
Test utilities for futures::sink
-
remem
Thread-safe object reuse
-
kvarn-quinn
Temporary Kvarn fork: Versatile QUIC transport protocol implementation
-
async-metronome
Unit testing framework for async Rust
-
libp2p-relay
Communications relaying for libp2p
-
tokio-dbus
Pure Rust D-Bus implementation for Tokio
-
stream-consumer-task
Start asynchronous task in background to consume stream
-
puzz-sse
Server-Sent Events (SSE) library for puzz
-
peace_item_sh_cmd
Manages running a shell command for the peace framework
-
async-gcode
An async gcode parser for no_std targets
-
memberlist-proto
Proto types and traits for the memberlist crate
-
pin-macros
primarly used to simplify the proccess of working with self-referencial structures
-
boluo-core
boluo的核心类型和特征
-
repeating_future
[RepeatingFuture] is a [Future] that can call an async function of an object over and over again
-
aranya-runtime
The Aranya core runtime
-
spire
The flexible scraper framework powered by tokio and tower
-
zino-channel
Cloud events and subscriptions for zino
-
crb-task
CRB | Composable Runtime Blocks | Task
-
gm-quic
An IETF quic transport protocol implemented natively using async Rust
-
smol-executor-trait
executor-trait implementation for smol
-
rama-utils
rama
-
rupnp
An asynchronous library for finding UPnP control points, performing actions on them and reading their service descriptions
-
takyon
single threaded async runtime
-
actix-files
Static file serving for Actix Web
-
mercury
The official Rust client for the Mercury Parser
-
bolt-client
A client that sends messages using the Bolt protocol
-
async-tungstenite
Async binding for Tungstenite, the Lightweight stream-based WebSocket implementation
-
peace_item_file_download
Manages downloading a file for the peace framework
-
openssh-sftp-client-lowlevel
Lowlevel utilities to communicate with openssh sftp server
-
nidrs-diesel
Nidrs & Diesel integration
-
madsim-tonic
The
tonic
simulator on madsim -
ntex-service
ntex service
-
async-backtrace
Efficient, logical 'backtraces' of async tasks
-
gloo-events
Convenience crate for working with DOM event listeners
-
poem-grpc-build
Codegen module of poem-grpc
-
compio-macros
Proc macro of compio
-
pollster-macro
Proc-macro crate for pollster
-
minechat-protocol
The MineChat protocol, enabling you chat with people over on Minecraft
-
one-file-raft
Raft consensus in 300 LOC
-
poem-mcpserver
MCP Server implementation for Poem
-
ruchei-extra
Stream/Sink wrapper with extra data, as used by ruchei
-
pexels-api
client for the Pexels API
-
picoserve
An async no_std HTTP server suitable for bare-metal environments
-
ntex-tokio
tokio intergration for ntex framework
-
async-graphql-tide
async-graphql for tide
-
yaar-reactor
Non-blocking IO abstractions for building executors
-
ohkami_lib
internal library for Ohkami - intuitive and declarative web framework
-
tokio-dbus-xml
Pure Rust D-Bus implementation for Tokio
-
embedded-platform
Holistic embedded device support in a batteries-included manner
-
mqtt-proto
MQTT v3.1/v3.1.1/v5.0 protocol sync/async codec
-
build_async
Rust Macros to Unify Synchronous and Asynchronous Codebases
-
fetchy
Async HTTPS fetch API built on pasts
-
tower-http-client
Extra Tower middlewares and utilities for HTTP clients
-
aldrin-parser
Aldrin schema parser library
-
direct-executor
An executor that directly executes futures, suitable for embedded environments
-
turboscraper
A high-performance, concurrent web scraping framework for Rust with built-in support for retries, storage backends, and concurrent request handling
-
tower-retry
Retry failed requests
-
tokio-tungstenite
Tokio binding for Tungstenite, the Lightweight stream-based WebSocket implementation
-
crb-actor
CRB | Composable Runtime Blocks | Actor
-
tokio01-test
Testing utilities for Tokio and futures-based code
-
rama-http
rama http layers, services and other utilities
-
openraft-sledstore
A sled based implementation of the
openraft::RaftStorage
trait -
ntex-server
Server for ntex framework
-
swiftide-core
Fast, streaming indexing, query, and agentic LLM applications in Rust
-
echannel
Async channel for mixed events
-
dialectic-null
A no-op backend for the Dialectic crate, intended for benchmarking and testing
-
rama-tcp
TCP support for rama
-
openraft-macros
Advanced Raft consensus
-
socks5-proto
Fundamental abstractions and async read / write functions for SOCKS5 protocol
-
zino-ntex
Integrations with ntex for zino
-
tower-reconnect
Automatically recreate a new
Service
instance when an error is encountered -
mptcp
A helper crate to create MPTCP sockets
-
agnostic_async_executor
Agnostic Rust Async Executor
-
ant-libp2p-webtransport-websys
WebTransport for libp2p under WASM environment
-
netapp
A toolkit library for distributed software
-
axum-server2
High level server designed to be used with axum framework
-
http-lib
High-level, asynchronous API for ureq, a safe HTTP client
-
tl-async-runtime
A bad runtime impl for educational purposes only
-
peace_fmt
Presentation and formatting support for the peace automation framework
-
crdb-test-utils
Concurrently Replicated DataBase
-
wirebolt
Lightweight and performant TCP wrapper
-
futures-macro-await
Definition of the
await!
macro for thefutures
crate -
volo-grpc
gRPC framework implementation of volo
-
just-watch
Async watch channel
-
ratchet_ext
WebSocket extensions for Ratchet
-
libp2p-floodsub
Floodsub protocol for libp2p
-
vertigo
Reactive Real-DOM library with SSR for Rust
-
ws_stream_wasm
A convenience library for using websockets in WASM
-
mendes
Rust web toolkit for impatient perfectionists
-
peace_rt_model_native
Runtime data types for the peace automation framework
-
dialectic-tokio-serde
A backend builder for the Dialectic crate using Serde serialization over Tokio transport
-
async-anthropic
Anthropic Rust Client
-
genawaiter2-proc-macro
procedural macro for generators (genawaiter2)
-
h3-shim
Shim libray between gm-quic and h3
-
websocket_toolkit
A WebSocket toolkit for Rust, enabling efficient real-time communication with flexible reconnection and message handling capabilities
-
ockam_node_no_std
Ockam library types that do not need
std
-
mfio-rt
mfio based async runtime
-
heim-runtime
Runtime shims for heim crate
-
tower-make
Trait aliases for Services that produce specific types of Responses
-
clia-ntex-files-mod
A mod to ntex-files, supporting '.' leading
-
async-h1
Asynchronous HTTP 1.1 parser
-
zino-amis
UI generator for amis
-
futures_ringbuf
Mock Type implementing AsyncRead/AsyncWrite for testing and examples
-
futures-mpsc
A futures aware, bounded, MPSC channel with back pressure support
-
compio-quic
QUIC for compio
-
memberlist-quic
memberlist's transport layer based on QUIC
-
tokio-tungstenite-typed
tokio-tungstenite with type safe messages
-
rxqlite-notification
A distributed sqlite database built upon
openraft
,sqlx
andsqlite
-
crb-agent-ext
CRB | Composable Runtime Blocks | Agent Ext
-
peace_rt_model_web
Web support for the peace automation framework
-
cobs-codec
COBS codec for Tokio
-
async-graphql-warp
async-graphql for warp
-
citadel_io
Underlying runtime for interfacing with I/O for std/wasm targets
-
peace_data
Data model for the peace automation framework
-
ratchet_core
Async WebSocket implementation
-
socketioxide-redis
Redis adapter for the socket.io protocol
-
htmxtools
A lightweight Rust crate for working with HTMX headers, specifically designed to integrate seamlessly with axum
-
peace_cmd_rt
Runtime types for commands for the Peace framework
-
aldrin-macros
Aldrin macros
-
aldrin-test
Aldrin server and client tests
-
futuresdr-remote
Remote interaction library for FutureSDR
-
postel
High level server for hyper and tower
-
libp2p-wasm-ext
Allows passing in an external transport in a WASM environment
-
swiftide-macros
Fast, streaming indexing, query, and agentic LLM applications in Rust
-
tower-timeout
Apply a timeout to requests, ensuring completion within a fixed time duration
-
crdb-postgres
Concurrently Replicated DataBase
-
citadel_types
Types for the citadel protocol
-
reqwest-streams
HTTP body streaming support for reqwest: JSON/CSV/Protobuf and others
-
firebase-rtdb
Firebase client for the Citadel Protocol
-
async-retry
Async Retry
-
task-stream
a global task executor, run in
no_std
-
rw-stream-sink
Adaptator between Stream/Sink and AsyncRead/AsyncWrite
-
libp2p-websocket-websys
WebSocket for libp2p under WASM environment
-
tower-async-service
Trait representing an asynchronous, request / response based, client or server. An "Async Trait" fork from the original Tower Library
-
ant-libp2p-relay
Communications relaying for libp2p
-
tokio-net
Event loop that drives Tokio I/O resources
-
zino-chatbot
Unified access to chatbot services for zino
-
async-wsocket
A convenience library for using websockets both in native and WASM environments! Include embedded tor client support
-
crb-pipeline
CRB | Composable Runtime Blocks | Pipeline
-
tower-load-shed
Immediately reject requests if the inner service is not ready. This is also known as load-shedding.
-
crb-supervisor
CRB | Composable Runtime Blocks | Supervisor
-
actix-storage
General key value storage for actix-web
-
qinterface
gm-quic's packet routing and definition of the underlying IO interface
-
tower-load
Strategies for measuring the load of a service
-
specta-macros
Macros for specta. Don't use directly!
-
memberlist-net
memberlist's transport layer based on TCP and UDP
-
test_executors
async executors for testing
-
actix-web-async-await
preview of Actix with async/await support
-
http-client
Types and traits for http clients
-
peace_item_blank
Copies a number from one resource to another
-
libp2p-pnet
Private swarm support for libp2p
-
mwc-libp2p
Peer-to-peer networking library
-
netbeam
a pure-rust asynchronous network synchronization crate (using tokio) that recreates familiar asynchronous paradigms but in a network context
-
rama-tls
tls implementations for rama
-
ant-libp2p-plaintext
Plaintext encryption dummy protocol for libp2p
-
peace_diff
Diff types for the peace automation framework
-
actix-connect
TCP connector service for Actix ecosystem
-
monoio-macros
Monoio proc macros
-
rama-socks5
SOCKS5 support for rama
-
tower-sessions-mongodb-store
MongoDB session store for
tower-sessions
-
doip_rw_tokio
Diagnostic over IP asynchronous API to implement a DoIP tester or entity
-
console-subscriber
A
tracing-subscriber::Layer
for collecting Tokio console telemetry -
tentacle-secio
Secio encryption protocol for p2p
-
async-std
Deprecated in favor of
smol
- Async version of the Rust standard library -
peace_cmd_model
Data types for commands for the Peace framework
-
axum-handle-error-extract
Error handling layer for axum that supports extractors and async functions
-
ntex-glommio
glommio intergration for ntex framework
-
zino-extra
Extra utilities for zino
-
crdb-indexed-db
Concurrently Replicated DataBase
-
tonic-web
grpc-web protocol translation for tonic services
-
elfo-core
The core of the elfo system
-
memberlist-core
A highly customable, adaptable, async runtime agnostic Gossip protocol which helps manage cluster membership and member failure detection
-
futures-async-stream-macro
detail of the
futures-async-stream
crate -
ntex-io
encoding and decoding frames
-
async-rustls
Asynchronous TLS/SSL streams using Rustls
-
kayrx-timer
The Kayrx Framework
-
ant-libp2p-websocket-websys
WebSocket for libp2p under WASM environment
-
libp2p-uds
Unix domain sockets transport for libp2p
-
crb-core
CRB | Composable Runtime Blocks | Core
-
peace_items
Collection of items the peace framework
-
basteh-redb
basteh based on redb
-
tonic-types
A collection of useful protobuf types that can be used with
tonic
-
citadel_wire
NAT traversal and wire support for the Citadel Protocol
-
axum-jrpc
A JSON-RPC extractor for Axum
-
tower-ready-cache
Caches a set of services
-
tower-service
Trait representing an asynchronous, request / response based, client or server
-
libp2p-dcutr
Direct connection upgrade through relay
-
rawst_dl
Snag your files efficiently with Rawst downloader
-
actix-tls
TLS acceptor and connector services for Actix ecosystem
-
winio
Single-threaded async GUI runtime based on compio
-
tokio-test
Testing utilities for Tokio- and futures-based code
-
libp2prs-core
Core traits and structs of libp2p
-
boluo
简单易用的异步网络框架
-
peace_value_traits
Trait bounds for value types for the Peace framework
-
ant-libp2p-ping
Ping protocol for libp2p
-
peace_resources
Runtime resources for the peace automation framework
-
tower-spawn-ready
Drives service readiness via a spawned task
-
actix-http-test
Various helpers for Actix applications to use during testing
-
ntex-net
ntexwork utils for ntex framework
-
rama-udp
UDP support for rama
-
mio-more
Extra components for use with Mio
-
aldrin-codegen
Aldrin code generator library
-
actix-threadpool
Actix thread pool for sync code
-
socket-flow
WebSockets implementation, to be used in clients and servers