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