-
async-std
Async version of the Rust standard library
-
tokio
An event-driven, non-blocking I/O platform for writing asynchronous I/O backed applications
-
futures
An implementation of futures and streams featuring zero allocations, composability, and iterator-like interfaces
-
actix
Actor framework for Rust
-
async-task
Task abstraction for building executors
-
tokio-rustls
Asynchronous TLS/SSL streams for Tokio using Rustls
-
async-graphql
A GraphQL server library implemented in Rust
-
async-io
Async I/O and timers
-
futures-lite
Futures, streams, and async I/O combinators
-
rdkafka
Rust wrapper for librdkafka
-
async-tls
Asynchronous TLS/SSL streams using Rustls
-
mobc
A generic connection pool with async/await support
-
nb
Minimal non-blocking I/O layer
-
futures-timer
Timeouts for futures
-
mlua
High level bindings to Lua 5.4/5.3/5.2/5.1 (including LuaJIT) with async/await features and support of writing native lua modules in Rust
-
futures-channel
Channels for asynchronous communication using futures-rs
-
heim
Cross-platform framework for system information
-
bb8
Full-featured async (tokio-based) connection pool (like r2d2)
-
mio
Lightweight non-blocking IO
-
mio-extras
Extra components for use with Mio
-
tokio-util
Additional utilities for working with Tokio
-
async-trait
Type erasure for async trait methods
-
blocking
A thread pool for isolating blocking I/O in async programs
-
dataloader
Rust implementation of Facebook’s DataLoader using async-await
-
ldap3
Pure-Rust LDAP Client
-
mio-uds
Unix domain socket bindings for mio
-
ghost_actor
GhostActor makes it simple, ergonomic, and idiomatic to implement async / concurrent code using an Actor model
-
fred
A Redis client for Rust built on Futures and Tokio
-
deadpool-redis
Dead simple async pool for redis
-
rio
GPL-3.0 nice bindings for io_uring. MIT/Apache-2.0 license is available for spacejam’s github sponsors.
-
message-io
Easy asynchronous network message library
-
futures_codec
Utilities for encoding and decoding frames using
async/await
-
redis-async
An asynchronous futures based Redis client for Rust using Tokio
-
smol-potat
Proc macro for smol runtime
-
tokio-native-tls
An implementation of TLS/SSL streams for Tokio using native-tls giving an implementation of TLS for nonblocking I/O streams
-
futures-intrusive
Futures based on intrusive data structures - for std and no-std environments
-
c-ares-resolver
An asynchronous DNS resolver, backed by c-ares
-
etcd-client
An etcd v3 API client
-
async_executors
Implements Spawn, SpawnLocal and SpawnHandle for commonly used executors
-
tmq
ZeroMQ bindings for Tokio
-
xtra
A tiny actor framework
-
rxrust
A Rust implementation of Reactive Extensions
-
tokio-pg-mapper
Proc-macro library used to map a tokio-postgres row to a Rust type (struct)
-
async-graphql-warp
async-graphql for warp
-
futures-retry
Retry your Futures and Streams!
-
tokio-compat-02
Tokio 0.2 compat utilities
-
tokio-serial
A serial port implementation for tokio
-
riker
Easily build fast, highly concurrent and resilient applications. An Actor Framework for Rust.
-
futures-signals
Zero cost FRP signals using the futures crate
-
celery
Rust implementation of Celery
-
genawaiter
Stackless generators on stable Rust
-
twilight-standby
Utility to filter wait for filtered incoming events for the Twilight ecosystem
-
minus
An asynchronous paging library for Rust
-
async-oneshot
A fast, small, full-featured, async-aware oneshot channel
-
capnp-futures
async serialization for Cap’n Proto messages
-
futures-locks
Futures-aware lock primitives
-
rants
An async NATS client library
-
smol
A small and fast async runtime
-
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)…
-
async-socks5
An async/.await SOCKS5 implementation
-
multer
An async parser for
multipart/form-data
content-type in Rust -
streamunordered
An efficient async stream multiplexer
-
lspower
Language Server Protocol implementation based on Tower
-
futures-io
The
AsyncRead
,AsyncWrite
,AsyncSeek
, andAsyncBufRead
traits for the futures-rs library -
async-native-tls
Native TLS using futures
-
deadpool-lapin
Dead simple async pool for lapin
-
stream-cancel
A library for interrupting asynchronous streams
-
eventsourcing
Event Sourcing for Rust
-
unicycle
A scheduler for driving a large number of futures
-
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.
-
pharos
Observer pattern which generates a futures 0.3 stream of events
-
maybe-async
A procedure macro to unify SYNC and ASYNC implementation
-
seq_io
Fast FASTA, FASTQ and FASTX parsing
-
streamline
Reversible futures::Stream-based state machines
-
nuclei
Proactive IO & runtime system
-
pinky-swear
Futures and async/await-ready Promises
-
synchronized-writer
A tiny implement for synchronously writing data
-
async-sse
Async Server Sent Event parser and encoder
-
heim-runtime
Runtime shims for heim crate
-
keycloak
Keycloak Admin REST API
-
tower-lsp
Language Server Protocol implementation based on Tower
-
protobuf_codec
Encoders and decoders for Protocol Buffers based on bytecodec crate
-
futures-micro
Zero dependency, no_std compatible async prelude
-
lifeline
Lifeline is a dependency injection library for asynchronous message-based applications
-
kuska-handshake
Secure Scuttlebutt handshake + boxstream library
-
opencl3
A Rust implementation of the Khronos OpenCL 3.0 API
-
libzmq
A strict subset of ØMQ with a high level API
-
tower
Tower is a library of modular and reusable components for building robust clients and servers
-
safina-timer
Safe async timers
-
domain-resolv
An asynchronous DNS stub resolver
-
next-gen
Safe generators on stable Rust
-
futures-task
Tools for working with tasks
-
smelling_salts
Start a thread to wake an async executor when the OS’s I/O event notifier discovers that the hardware is ready
-
cursive-async-view
A loading-screen wrapper for gyscos/cursive views
-
torut
torut is reasonable tor controller written in rust utilizing tokio for async communication
-
aiven_rs
This is a rust sdk to interact with aiven-cloud apis
-
named-binary-tag
Format is used by minecraft for the various files in which it saves data
-
async-ctrlc
Async wrapper of
ctrlc
-
a2
A native, asynchronous Apple push notification client
-
again
wasm-compatible retry util for std library futures
-
zookeeper-async
An async ZooKeeper client
-
dkregistry
A pure-Rust asynchronous library for Docker Registry API
-
tokio-io-timeout
Tokio wrappers which apply timeouts to IO operations
-
scoped_spawn
Full structured concurrency for asynchronous programming
-
futures-sink
The asynchronous
Sink
trait for the futures-rs library -
messagebus
MessageBus allows intercommunicate with messages between modules
-
wikidot-normalize
Simple library to provide Wikidot-compatible string normalization
-
ksoft
KSoft.SI api wrapper written in pure Rust
-
ert
A combinator to control future execution order
-
triggered
Triggers for one time events between tasks and threads
-
async-raft
An async implementation of the Raft distributed consensus protocol
-
async_logger
Asyncronous logger allows writing arbitrary slices to a memory buffer, which then processed by a writer in it’s own thread
-
agnostik
Executor Agnostic Runtime that can run your futures with your favourite Executor
-
tbot
Make cool Telegram bots with Rust easily
-
persway
Sway IPC daemon
-
stakker
A lightweight low-level single-threaded actor runtime
-
background-jobs-core
Core types for implementing an asynchronous jobs processor
-
pcap-async
Async/Stream Extensions for libpcap
-
queen-io
I/O library for Rust
-
async-change-tracker
reactive change notifications using futures
-
vmap
Cross-platform library for fast and safe memory-mapped IO
-
csv-async
CSV parsing for async
-
mio-serial
A serial port implementation for mio
-
etcd-rs
etcd client for rust
-
mpart-async
Asynchronous (Futures-Base) Multipart Requests for Rust
-
tokio-serde-cbor
Integration of serde_cbor into tokio-io, to allow sending CBOR encoded frames across network (and possibly through other transports)
-
async-codec
Utilities for creating async codecs
-
lamellar
Lamellar is an asynchronous tasking runtime for HPC systems developed in RUST
-
rustun
A library for implementing STUN server and client asynchronously
-
reool
An asynchrounous connection pool for Redis based on tokio and redis-rs
-
mobc-redis
Redis support for the mobc connection pool
-
nakadi-types
A connector for the Nakadi Event Broker
-
mux-stream
Asynchronous hierarchical update dispatching for Rust
-
if-watch
crossplatform asynchronous network watcher
-
async-tun
Asynchronous allocation of TUN/TAP devices using async-std
-
lazy_async_pool
An asyncronous object pool that generates objects on the fly
-
dbus-async-derive
Handler trait derive macro for dbus-async
-
quicksink
Create a Sink from some value and a closure returning a Future
-
beatsaver-rs
A Rust library for interacting with the beatsaver.com api
-
packet-ipc
Share packets between services using servo ipc
-
separator
Formats numbers into strings with thousands separators for readability
-
async-hsm
The lightweight asynchronous hierarchical state machine (HSM)
-
async_msp_cli
Async msp cli for iNav and BetaFlight
-
trait-async
Type erasure for async trait methods
-
paypal-rs
A library that wraps the paypal api asynchronously
-
event-emitter-rs
Lightweight EventEmitter
-
blocking-permit
Permits and a thread pool for blocking operations
-
async_once
async once tool for lazy_static
-
async-ssh2-lite
Asynchronous ssh2
-
miau
Async aware and extensible layered configuration system
-
iou
io_uring bindings
-
fibers
A Rust library to execute a number of lightweight asynchronous tasks (a.k.a, fibers) based on futures and mio
-
lsp-codec
Simple Tokio 0.1-based Codec implementation for Language Server Protocol
-
futures-delay-queue
Async delay queue backed by async-std and futures-timer
-
async_io_stream
IntoAsyncRead on steriods
-
tokio-file-unix
Asynchronous support for epollable files via Tokio on Unix-like platforms
-
event-listener
Notify async tasks or threads
-
futures-x-io-timeoutable
Timeout ext for futures io and tokio io
-
tokio-stream
Utilities to work with
Stream
andtokio
-
kompact-component-derive
A derive macro for Kompact component definitions
-
async-graphql-actix-web
async-graphql for actix-web
-
heim-process
Cross-platform processes information
-
asynchronous-codec
Utilities for encoding and decoding frames using
async/await
-
futures-rate
This library provides easy tools to help Rust applications guide critical resources or code paths from being overwhelmed
-
pretty-exec-lib
Print a command and then execute it
-
async-log
Async tracing capabilities for the log crate
-
acteur
A safe actor-like framework that just works. Simple, robust, fast, documented.
-
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. -
rmp-futures
Async Rust MessagePack and MessagePack-RPC
-
cb_fut
Call function that return value via callback without a callback
-
craftio-rs
A crate to read & write packets defined in mcproto-rs to I/O sinks/sources
-
actix-daemon-utils
Daemon Utilities by actix
-
messagebird-async
Wrapper around the message bird SMS API
-
panda
An async Rust library for Discord
-
thin_main_loop
Thin, cross-platform, main event loop. A building block for native GUI applications, among other use cases.
-
etcdv3client
a simple etcdv3 client
-
want
Detect when another Future wants a result
-
chopper
Chopper is a streaming time series manipulation framework. Cli frontend is provided via chop crate.
-
openai-api
OpenAI API library for rust
-
libevent
Rust bindings to the libevent async I/O framework
-
poolparty
Added functionality for the
futures::executor::ThreadPool
futures executor -
async-mq
Zero-cost async-await abstraction of lapin AMQP client crate
-
async-recursion
Recursion for async functions
-
stream_throttle
Provides a Stream combinator, to limit the rate at which items are produced
-
leaves
Distributed ID Allocator
-
async-scoped
Spawn scoped (non ’static) asynchronous futures for async_std and tokio runtimes
-
rustmann
Rust/Tokio client for Riemann
-
smol-timeout
A way to poll a future until it or a timer completes
-
reqchan
This is a 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…
-
async_zmq
Async version for ZeroMQ bindings
-
linemux
A library providing asynchronous, multiplexed tailing for (namely log) files
-
stream_router
A Future aware router to dynamically route between Streams and Sinks
-
kad
A generic / futures based implementation of the Kademlia Distributed Hash Table (DHT)
-
lib3h_zombie_actor
lib3h actor request tracking module
-
juggle
Async task switching for cooperative multitasking in single thread environments with no_std support
-
libaio-futures
Straightforward Linux AIO using Futures/async/await
-
eventually-postgres
Event Store implementation using PostgreSQL for the Eventually crate
-
one-of-futures
Future-aware Either-like type with multiple variants
-
ur20
Rust library for the Weidmüller u-remote IP20 system
-
appliance
A lightweight framework to build components with message-based intercommunications
-
scipio
A set of utilities to allow one to write thread per core applications
-
termion-input-tokio
An adapter that exposes termion’s input and key event iterators as asynchronous streams
-
safina-executor
Safe async runtime
-
conch-runtime
A library for evaluating/executing programs written in the shell programming language
-
io-surface
Bindings to IO Surface for macOS
-
signalbool
A simple crate to catch signals and set a boolean flag for later use
-
tokio-lxi
LXI protocol abstractions for Tokio
-
lua_actor
Lua Actor for Rust(sync/async)
-
actori
Actor framework for Rust
-
fb_futures_ext
Crate extending functionality of futures crate
-
stakker_mio
Mio I/O polling integration for the Stakker crate
-
d3-components
A framework for server development – the component layer
-
waitgroup
Async waitgroup for a collection of task to finish
-
tokio-zmq
Provides Futures abstractions for ZeroMQ on the Tokio event-loop
-
agnostik-attributes
Executor agnostik attributes
-
async-reply
Library to handle typed messages and replies
-
double-checked-cell-async
A thread-safe lazily initialized cell using double-checked locking
-
frappe
Functional Reactive Programming library for Rust
-
deadqueue
Dead simple async queue
-
pwner
Pwner is a Process Owner crate that allows ergonomic access to child processes
-
promising-future
Implementation of Promise/Future pairs
-
automate
An asynchronous library to interact with Discord API and make bots
-
pantry
Temporary storage for reusing values that may decay
-
nbd-async
Block device drivers in userspace
-
vampirc-io
A library for asynchronous, non-blocking, UCI protocol–based communication between chess UIs and chess engines
-
thread_timer
A simple, cancelable timer with no external dependencies
-
zeebe
A rust client for defining, orchestrating, and monitoring business processes across microservices using Zeebe
-
tokio-socketcan-bcm
Asynchronous Linux SocketCAN - Broadcast Manager support (BCM) with tokio
-
tokio-ddmw
Utility library for integrating clients against DDMW
-
actor-es
An event sourcing + CQRS abstraction on top of Riker
-
async_smux
Asynchronous smux multiplexing library
-
suspend
A common mechanism for suspending a thread or a Future until notified
-
poller
File I/O events library for Rust
-
yaaf
Yet Another Actor Framework
-
stund
An SSH tunnel maintenance daemon
-
async-global-executor
A global executor built on top of async-executor and async-io
-
async-executor
Async executor
-
untokio
Automatically create tokio runtimes
-
thruster-async-await
An async await shim for the thruster web framework
-
signald-rust
A library to interface with Signald
-
webhdfs
Hadoop WebHDFS client library
-
fluvio-future
I/O futures for Fluvio project
-
par-stream
Asynchronous parallel streams analogous to rayon
-
blocker
Block rust futures to create a synchronous wrapper around an asynchronous api
-
nbchan
Highly optimized non-blocking communication channels
-
async-object-pool
A simple object pool implementation that uses asynchronous synchronization primitives only
-
futures-cache
Futures-aware cache backed by sled
-
mio-signals
Crate for handling signals with Mio
-
futures-rustls
Asynchronous TLS/SSL streams for futures using Rustls
-
async-trait-ext
a procedural macro for async traits
-
lwactors
Lightweight actors for Rust using futures-rs
-
dialectic
Transport-polymorphic, asynchronous session types for Rust
-
implicit-await
Implicitly await calls returning Future impls
-
heim-cpu
Cross-platform CPU information
-
kube-derive
Custom derives for the kube kubernetes crates
-
dencode
Utilities for decoding and encoding frames from readers and writers
-
potential
Borrowing for futures - Potential enables interior mutation using mutex and asynchronous borrowing (leasing) through a oneshot channel
-
extreme
Extremely boring async function runner. MIT/Apache-2.0 license is available for spacejam’s github sponsors.
-
intervalier
Interval events with handling notifications
-
gain-lep
Support for exposing Gain APIs via Lep
-
cl3
A Rust implementation of the Khronos OpenCL 3.0 API
-
async-trait-with-sync
async-trait
withSync
patch -
tokio-pg-mapper-derive
Proc-macro library used to map a tokio-postgres row to a Rust type (struct)
-
moodyblues-sdk
A tracer SDK for Overlord like consensus algorithm
-
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
-
coerce
Async actor runtime and distributed systems framework
-
luis_sys
FFI bindings for Microsoft LUIS API
-
async-speed-limit
Asynchronously speed-limiting multiple byte streams
-
async-fuse
Helpers for fusing asynchronous computations
-
amy
Polling and Registration abstractions around kqueue and epoll for multithreaded async network programming
-
must_future
A wrapper future marked must_use - mainly to wrap BoxFutures
-
bb8-bolt
A bolt-client adaptor for the bb8 connection pool
-
tari_pubsub
Single publisher with multiple subscribers to topic messages
-
futures-await-await-macro
Definition of the
await!
macro for thefutures-await
crate -
requiem
Actor framework for Rust
-
futures-diagnose
Wraps around a Spawn and provides lots of diagnostics
-
ardop_interface
Interface to the Amateur Radio Digital Open Protocol (ARDOP)
-
tokio-dns-unofficial
Unofficial extension to tokio to provide asynchronous DNS resolution
-
epoxy_frp
The Reactive Glue for Frontend Applications
-
iobuffer
A simple memory-based buffer for IO reading and writing
-
async-walkdir
Asynchronous directory traversal for Rust
-
cntrlr
Simple, async embedded framework
-
data-buffer
A simple low-level data buffer type useful for IO and in homogeneous collections
-
tokio-pipe
Asynchronous pipe(2) library using tokio
-
rust-cli-commands
rust-cli-commands
-
tokio-tun
Asynchronous allocation of TUN/TAP devices using tokio
-
completion
Utilities for writing completion-based asynchronous code
-
tokio-nsq
A Rust NSQ client built on Tokio. Tokio NSQ aims to be a feature complete NSQ client implementation.
-
signals
A functional-reactive-like library for Rust that allows asynchronous chaining
-
ws-gonzale
Naive websocket server implemented using async / await
-
tokio-diesel
Integrate Diesel into Tokio cleanly and efficiently
-
futures-mockstream
Minimal mockstream which implements futures async traits
-
tg_botapi
Telegram Bot Api library
-
postage
An async channel library
-
gabelung
Branch an asynchronous stream of cloneable items into two
-
async-trait-static
async fn in trait for no_std
-
read-progress-stream
Stream reader wrapper that tracks the number of bytes read
-
thunks
Asynchronous composer for Rust
-
async-proxy
An asyncronous implementation of proxy clients
-
pollster
A minimal async executor that lets you block on a future
-
skyblock-rs
A simple library to interact with Hypixel’s Skyblock API
-
tokio-async-std
An async-std that can fit into tokio ecosystem straight ahead
-
parity-runtime
Tokio runtime wrapper
-
broadcast
A rustlang adapter for writing to multiple sources
-
async-watch
Async watch channel
-
async-backplane
Simple, Erlang-inspired reliability backplane for Rust Futures
-
async-ssh2
Async wrapper over ssh2
-
rtl8139-rs
no_std rtl8139 driver with async and sync interfaces
-
async-pipe
Creates an asynchronous piped reader and writer pair using tokio.rs
-
real-async-trait
A proc macro that uses experimental features to work around type erasure for async traits
-
syncthing
A Rust library for controlling syncthing file synchronization through its REST interface
-
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.)
-
webex
Interface to Webex Teams REST and WebSocket APIs
-
reverse_io
A wrapper type allowing the reversing of std::io::{Read, Write, Seek}
-
gen-z
Macro-free stream construction through asynchronous generators via an awaitable sender
-
rlink-buffer-gen
High performance Stream Processing Framework
-
rustracts
Rust crate for cancellable time based contracts in async/await
-
restartables
Future that restarts an inner future if it doesn’t meet a condition
-
fastcgi-client
Fastcgi client implemented for Rust
-
dyn-future
Convenient and fast dynamic Futures for Rust
-
spekt
std::future::Future and Result-based testing trait for managing the lifecycle of stateful, asynchronous tests
-
futures-test-preview
Common utilities for testing components built off futures-rs
-
spin_on
A simple, inefficient Future executor
-
iterstream
Converts Iterator into real asynchronous Stream
-
transform-stream
Lightweight async stream wrapper
-
tower-ready-cache
Caches a set of services
-
sidekiq-rs
Sidekiq compatible server in Rust
-
stream_multiplexer
Combines many streams into a few
-
async-await
Just some macros to emulate the Async and Await :)
-
noob
A WIP futures-based Discord bot library
-
tokio-non-async
Helpers for dealing with tokio channels in non-async code
-
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.
-
futures-core
The core traits and types in for the
futures
library -
futures-async-combinators
toy futures combinators
-
pasts
Minimal and simpler alternative to the futures crate
-
mio-timerfd
mio support for linux’s timerfd
-
shiori_hglobal
impl str for HGLOBAL{…}
-
async-gitlib
Asynchronous library with libgit2 artifacts
-
tranquility
A Rust library for the Reddit API
-
tauri-async-handler
A async handler for tauri
-
io-synesthesist
ffi library of write(2) and lseek(2)/read(2)
-
rlua-async
Async support for rlua, via coroutines
-
async-stream-packed
Asynchronous stream packed
-
ipc-orchestrator
Orchestion of command line processes for local dev usage with IPC communication
-
ckb-async-runtime
CKB async runtime wrapper
-
actors-macros
Macro crate for Riker actor framework
-
fluvio-async-tls
Asynchronous TLS/SSL streams using Rustls
-
fastlog
A high performance asynchronous logger
-
actix-raft
An implementation of the Raft distributed consensus protocol using the Actix actor framework
-
futuristic
Extensions to the futures crate
-
async-minecraft-ping
An async Rust client for the Minecraft ServerListPing protocol
-
stream-map-any
Allows merging async Streams of different output type
-
tokio-test
Testing utilities for Tokio- and futures-based code
-
git-event
Customizable event handler for updates in remote git repositories
-
async-priority-queue
An async-aware priority queue
-
selecting
Cross-platform over select
-
strawpoll
A wrapper to avoid spurious polling
-
core-futures-tls
A libcore wrapper allowing async/await to be used from no_std crates
-
deferred
Rust crate to help perform deferred execution of code logic
-
tcpclient
Asynchronous tcpclient based on aqueue actor
-
spaad
Zero boilerplate actor systems with xtra
-
message_plugins
A Message-Passing Oriented backbone for Rust plugins to Rust programs
-
visiting_ref
Container types that asynchronously return ownership of a value to another context upon exiting scope
-
async-select-all
A futures library adapter for selecting over a list of futures
-
dbus-async
Asynchronous DBus library
-
tokio-lk
Futures-aware lock-by-id primitives
-
cqrs-core
Core types and traits for cqrs
-
async-weighted-semaphore
An async weighted semaphore
-
tk-listen
A set of helper futures allowing to listen TCP (or unix) socket with resource limits and proper error handling
-
tiny_future
This library provides spin-loop-free futures and a helper functions to run a job asynchronously
-
oxiunify
In development, not production-ready yet. Exploring more futures primitives. Rust guidelines for webapps pursuing the safety of Rust, the minimalism of Go, the performance of C++, and…
-
futures-x-io
Compatible with futures io and tokio io
-
capella
An asynchronous StatsD clone
-
futures-test
Common utilities for testing components built off futures-rs
-
async-injector
Reactive dependency injection for Rust
-
aktrs
An actor model framework for Rust
-
futures-signals-structs
Derives mutable versions of structs for the futures-signals crate
-
async-attributes
Experimental language-level polyfills for Async Rust
-
wait-for-me
Async CountDownLatch
-
kompact-actor-derive
A derive macro for Kompact Actors
-
reactive-rs
FRP in Rust: streams and broadcasts
-
ex-futures
An extension of
futures
-
tokio-stdin-stdout
Thread- and future::sync::mpsc-based AsyncRead/AsyncWrite stdin/stdout with little buffering
-
heim-net
Cross-platform network information
-
linked-futures
Link futures into a block, which stops all of the included futures when any of the futures complete
-
dapr-derive
Dapr SDK for Rust
-
async-graphql-parser
GraphQL query parser for async-graphql
-
tokio-prepend-io
Wrapper types that prepends data when reading or writing with AsyncRead or AsyncWrite
-
zeebest
An unofficial zeebe client for the future!
-
async-lease
Essentially a futures-oriented Arc<Mutex<Option>>
-
ws_stream_tungstenite
Provide AsyncRead/AsyncWrite over Tungstenite WebSockets
-
async-wormhole
Async calls across non-async functions
-
manual_future
A future that must be manually completed, similar to Java’s CompletableFuture
-
polling
Portable interface to epoll, kqueue, event ports, and wepoll
-
retrio
Wrapper around readers and writers to retry on errors of kind Interrupted
-
futures-cputask
Turn synchronous CPU-bound tasks into futures
-
async-gcode
An async gcode parser for no_std targets
-
poem
A web framework built around async/await
-
jason
JSON-RPC 2.0 client library
-
openweather-async
An async library for use with the openweathermap.org API
-
misskey-core
Core traits and types in misskey-rs
-
aiur
Async executor with structured concurrency
-
slog-scope-futures
slog-scope for
Future
s -
async-stream-tls-upgrader
Asynchronous stream tls upgrader
-
streams-rs
OCaml like streams for Russt
-
wolfram_alpha
A library providing Rust bindings for the Wolfram|Alpha API
-
futures-jsonrpc
Futures implementation for JSON-RPC
-
tokio-file
Asynchronous file I/O for Tokio
-
newsblur_api
rust implementation of the NewsBlur-API
-
c3p0_common_async
A good friend for r2d2
-
ksway
Crate for interfacing with sway/i3 ipc
-
nsq-client
Rust client for the NSQ realtime message processing system
-
tokio-beanstalkd
Asynchronous client library for interacting with Beanstalkd work queue
-
back-to-the-future
Conversions between std::future::Future and futures::Future
-
woke
A minimalistic waker implementation for executors
-
settimeout
Creates a std::future::Future implementation to be ready at some point
-
eventum
Asynchronous I/O Event manager
-
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. -
beeswax
An easy to use CRUD client for the Beeswax API
-
raii-counter-futures
RAII Counter that allows you to wait for a count of zero asynchronously
-
d3
A framework for server development
-
quickcheck_async
Runtime-agnostic attribute macros to use quickcheck with async tests
-
lamellar-impl
Lamellar is an asynchronous tasking runtime for HPC systems developed in RUST
-
async_msp_lib
Async msp library for iNav and BetaFlight
-
bawawa
Opinionated set of tools to manage and compose process executions
-
callback-future
Adapter between callbacks and futures
-
opentracing-rs
opentracing for rust
-
mrwei
A simple library that implements the common promise primitive for rust based on std future
-
tokio-either
Either for Tokio
-
revent
Event system for Rust
-
openrazer
Asynchronous bindings to the OpenRazer daemon
-
sync-async-runner
Run async functions synchronously (like coroutines)
-
eventific
Eventific is a tool that gives you the needed building blocks for event sourcing
-
futures-net
The futures-net library
-
tokio-rpc
An RPC framework for Rust base on tokio
-
bottle
Actor model framework for Rust
-
gen-stream
Generator-based streams for Rust and futures 0.3
-
ara
Async random access I/O traits
-
greenthread-future
Convert closures to futures based on greenthread on bare-metal (no_std + no_alloc)
-
deepwell-core
Database management and migrations service
-
cppStream
a wrapper brings
<<
and>>
operator to rust’s writer/reader/stream like what C++ did -
zomato
A simple crate for retrievig daily menu from zomato.com
-
async_value
Simple, persistent, asynchronous values
-
waitout
Awaits the completion of multiple async tasks
-
component-future
implements the inner future protocol documented in the tokio docs
-
gio-2-0-sys
Import crate for Gio
-
stateful_async_worker
Asynchronous stateful worker threads utilizable as futures
-
ferris-extensions
Extension macros for Rust
-
async-google-apis-common
Shared code for the async-google-apis generated code
-
sgx_core_futures
Rust SGX SDK provides the ability to write Intel SGX applications in Rust Programming Language
-
safina-sync
Safe async select function, for awaiting multiple futures
-
duplexify
Combine a reader + writer into a duplex of Read + Write
-
tang-rs
A light weight asynchronous connection pool
-
handlers
A macro for generating systems of event handlers
-
tokio-uds-proto
Unix Domain sockets working with tokio-proto
-
async-os
deleted - email help@crates.io to claim this crate name
-
eventually-redis
Event Store implementation using Redis, for Eventually crate
-
cute-async
Cute async utilities
-
side-futures
Send future for execution on the runtime that may be in a different thread
-
async-ringbuffer
A nonblocking spsc ring buffer with fixed capacity
-
monzo-lib
async Monzo client in pure rust
-
bitstream
Bit level IO
-
waitlist
Keep track of an ordered list of Wakers to wake
-
flv-future-aio
I/O futures for Fluvio project
-
dynamodb-mutex
Use Dymanodb mutex library
-
tokio-qapi
QEMU QMP and Guest Agent API tokio adapter
-
radix-router
Rust port of httprouter
-
async-coap
A flexible, asynchronous library for using and serving CoAP resources. Experimental.
-
tempest-source-redis
Tempest source implementation for Redis Streams
-
relay
A lightweight oneshot Future channel
-
deadpool-memcached
Dead simple async pool for memcached
-
librdkafka-sys
Native bindings to the librdkafka library
-
tokio-global
Global tokio runtime
-
mai
A higher-level mio interface
-
driver_async
async backend for
btle
,bluetooth_mesh
andusbw
crates -
plumbum
Conduit-like data processing library
-
boomerang
Rust implementation of “Reactors” Deterministic Actor Model
-
kyansel
Cancellable future. Provide a future as argument and the current future will cancel if the provided future resolves first
-
futures-dagtask
DAG-based Task Queue
-
glommio
A set of utilities to allow one to write thread per core applications
-
async-memcached
An Tokio-based memcached client for Rust
-
brawlhalla
An async Brawlhalla API Wrapper using tokio
-
mpool
A generic connection pool
-
tower-buffer
Buffer requests before dispatching to a
Service
-
yaaf-macros
Procedural macros for using YAAF
-
runtime-loop
Runtime loop for Rust
-
mio-st
Single threaded, lightweight non-blocking IO
-
actori-testing
Actori testing utils
-
mio-pipe
Crate for using Unix pipes with Mio
-
async-uninet
Unified types for asynchronous TCP & Unix sockets
-
tokio_safe_block_on
Provides the ability to execute async code from a sync context, without blocking a tokio core thread or busy looping the cpu
-
archlinux-repo
Arch Linux repositories parser
-
erkpht-tower
Tower is a library of modular and reusable components for building robust clients and servers
-
heim-disk
Cross-platform disk information
-
tangle
Future implementation for Rust
-
rotor-tools
Various utility things for comfortable writing of application and protocols using rotor library
-
genawaiter-macro
Convenience macros for generators (genawaiter)
-
stream-body
An HttpBody implementation with efficient streaming support for the Rust HTTP library hyper
-
io-block
Work with block devices and other block-like things in rust
-
executor-trait
A collection of traits to define a common interface across executors
-
num_stream
Rust crate that provides a Stream that yields incrementing numbers at a specified interval
-
async-shell
Asynchronous process child wait
-
mqtt-async-client
An MQTT 3.1.1 client written in Rust, using async functions and tokio
-
mirai
A Futures layer over Mio
-
dropbear
Awaitable drop container based on Tokio oneshots
-
RobotS
Actor framework
-
futures-promises
Promises and Watched Variables for Futures
-
future-by-example
Examples of common patterns using Future
-
redis-asio
Asynchronous Redis driver based on tokio
-
gw2rs
A Rust library for the Guild Wars 2 API
-
mio-utun
Utun bindings for mio
-
async-stream-http-tunnel-grader
Asynchronous stream http tunnel grader
-
event_dispatcher
A simple library to register listeners (with priority) for specific events inspired by rust-emitter
-
tokio-utun
Utun bindings for Tokio
-
async-diesel
Integrate Diesel into async-std cleanly and efficiently
-
async-reply-derive
Derive macros for
async-reply
messages -
eventsourcing-derive
Custom derive macros for Eventsourcing components
-
async-vfs
Async Virtual File System
-
mango-client
Fetch data from selfhosted mango instances
-
rsevents-extra
Useful events built on top of rsevents. Includes countdown event.
-
futures-fs
A Futures implementation for File System operations
-
tls-async
TLS support for AsyncRead/AsyncWrite using native-tls
-
promises
Effective, simple, lightweight Javascript promises in Rust
-
await_macros
Macros that expand to
(expr).await
-
riker-default
Riker’s default Model and modules providing core services
-
task-compat
Utility crate to compat futures 0.1 and futures 0.3 tasks
-
futurify
Convert your sync functions into non-blocking thread futures
-
async-test-derive
Procedure macro to run async fn as test
-
memstore
An in-memory implementation of the
async-raft::RaftStorage
trait -
mio-pidfd
mio support for Linux’s pidfd
-
hl7-mllp-codec
A Tokio codec for HL7 Minimal Lower Layer Message Transport protocol (MLLP)
-
completion-io
Core traits and types for asynchronous completion-based I/O
-
scambio
Safe and efficient value exchanges between endpoint pairs
-
thespis_impl
Reference implementation for the thespis actor model
-
rsmq_async_lite
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
-
async-stream
Asynchronous streams using async & await notation
-
retry_fn
A simple retry function with versions for blocking or non-blocking, tokio or async-std
-
futures-async-stream
Async stream for Rust and the futures crate
-
proq
Idiomatic Async Prometheus Query (PromQL) Client for Rust
-
psbus
Generic Publish / Subscribe model for application messaging
-
lelet
golang like task executor
-
futures-zmq
Provides Futures abstractions for ZeroMQ on any futures executor
-
wombo
Utilities for managing event loop threads
-
async-consul
An Tokio-based Consul client for Rust
-
stream-flatten-iters
Flattens a stream of iterators into one continuous stream
-
spin_future
Convert synchronous functions into valid but inefficient futures
-
tokio-signal
An implementation of an asynchronous Unix signal handling backed futures
-
tokio-macros
Tokio’s proc macros
-
sendfile
Sendfile is a wrapper around the sendfile(2) system call
-
async-graphql-tide
async-graphql for tide
-
async-fs
Async filesystem primitives
-
async-dup
Duplicate an async I/O handle
-
async-process
Async interface for working with processes
-
suspend-channel
Channel and stream implementations
-
thetvdb
TheTVDB API async client
-
async-sync
deleted - email help@crates.io to claim this crate name
-
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.
-
handy_async
A handy library for describing asynchronous code declaratively
-
lazy-queue
Futures-driven lazy queue processing
-
tk-pool
Generic connection pool for tokio
-
kompact
Kompact is a Rust implementation of the Kompics component model combined with the Actor model
-
misskey-util
High-level API for the misskey-rs library
-
core-futures-stateless
Workaround for no_std async-await that doesn’t store task contexts
-
async_ctx
Asynchronous contexts
-
implicit-await-macro
#[implicit_await] procedural macro implementation
-
ruyi
An event-driven framework for non-blocking, asynchronous I/O in Rust
-
async-core
deleted - email help@crates.io to claim this crate name
-
d3-core
A framework for server development – the core layer
-
yaar-reactor
Non-blocking IO abstractions for building executors
-
futures-executor
Executors for asynchronous tasks based on the futures-rs library
-
ndless-async
Ndless-specific integration with async/await for the TI-Nspire
-
safina-net
Safe async network functions
-
extern_executor
Async executor which delegates futures polling to external event-loop
-
coerce-rt
Async actor runtime
-
zoomies
An asynchronous DogStatsD client
-
opendht
A Rust API for OpenDHT
-
async-resource
Async resource pool
-
riker-macros
Macro crate for Riker actor framework
-
gj
Event loop and promises
-
catty
Send and await a value asynchronously
-
strife
A lightweight library for the Discord API
-
safina-select
Safe async select function, for awaiting multiple futures
-
futures-option
Extension traits for dealing with optional futures and streams
-
deepwell
Database management and migrations service
-
futures-polling
An enum similar to Poll, but containing a future in its Pending variant
-
rlink-buffer
High performance Stream Processing Framework
-
misskey-api
API bindings of Misskey, including requests/responses of endpoints and messages on channels
-
futures-async-runtime-preview
Runtime for the async/await macros in the
futures
crate -
futures_cbor_codec
A codec for framing an AsyncRead/AsyncWrite with cbor for all types that are serializable with serde
-
heim-memory
Cross-platform memory information
-
ws-lite
Naive websocket server implemented using async / await
-
local-pool-with-id
A minor variation on a LocalPool executor which exposes unique IDs for tracking future completion
-
safina-threadpool
Safe thread pool
-
tokio01-test
Testing utilities for Tokio and futures-based code
-
tokio-compat
Compatibility between
tokio
0.2 and legacy versions -
tower-retry
Retry failed requests
-
async-ready
Async readiness traits
-
asynchronous
Promises Q style , async and event loops
-
ufut
Just an alias of ‘futures-micro’
-
xactor
Xactor is a rust actors framework based on async-std
-
async-thread
Futures version of std::thread
-
async-ext
deleted - email help@crates.io to claim this crate name
-
multitask
An executor for running async tasks
-
associated-async-io
Async IO traits that use futures instead of poll
-
heim-sensors
Cross-platform sensors information
-
alzheimer
Async implementation of brainfuck interpreter
-
barrage
An async broadcast channel
-
futures-io-traits-sync-wrapper
futures::io::Traits(AsyncBufRead, AsyncRead, AsyncSeek and AsyncWrite) sync wrapper
-
puddle
A simple object pool implementation that uses asynchronous synchronization primitives only
-
safina-async-test
Macro for running async tests
-
future_pubsub
A tokio based publish-subscibe channel
-
mdrv
Modular driver based on Mio for managing multiple connections over different protocols
-
async-smtp-lite
Asynchronous smtp
-
thespis
The interface of the thespis actor model (contains only traits)
-
futures-select-macro-preview
The
select!
macro for waiting on multiple differentFuture
s at once and handling the first one to complete -
futures-await-async-macro
Definition of the
#[async]
macro for thefutures-await
crate as well as a few other assorted macros -
async-watch2
Async watch channel
-
async-graphql-derive
Macros for async-graphql
-
futures-async-stream-macro
Implementation detail of the
futures-async-stream
crate -
direct-executor
An executor that directly executes futures, suitable for embedded environments
-
tower-timeout
Apply a timeout to requests, ensuring completion within a fixed time duration
-
completion-core
Core traits and types for completion-based asynchronous programming
-
async-http1-lite
Asynchronous http1 stream
-
async-quic
deleted - email help@crates.io to claim this crate name
-
async-injector-derive
A derive to help construct dependent values in async-injector
-
futures-enum
#[derive(Future, Stream, Sink, AsyncRead, AsyncWrite, AsyncSeek, AsyncBufRead)] for enums
-
yaar
Yet another asynchronous runtime optimized around configuration and no_std
-
remem
Thread-safe object reuse
-
async-tls-lite
Asynchronous TLS/SSL streams using Rustls
-
d3-derive
A framework for server development – the derive macro
-
handy_io
A handy pattern and futures based asynchronous I/O library
-
genawaiter-proc-macro
procedural macro for generators (genawaiter)
-
futures-util
Common utilities and extension traits for the futures-rs library
-
redis_tang
A light weight asynchronous connection pool for redis-rs
-
tokio-executor-trait
executor-trait implementation for tokio
-
eternal-macro
The Eternal Framework
-
async-bench
deleted - email help@crates.io to claim this crate name
-
async-spawner
executor independent task spawner
-
async-rustls
Async TLS/SSL streams using rustls
-
async-compat
Compatibility adapter between tokio and futures
-
heim-host
Cross-platform host information
-
runtime-attributes
Proc Macro attributes for the Runtime crate
-
async_chanx
UPDATE ME
-
tokio-buf
Asynchronous stream of byte buffers
-
async-macros
Macros for async-std
-
async-graphql-value
GraphQL value for async-graphql
-
tower-balance
Balance load across a set of uniform services
-
tokio-reactor
Event loop that drives Tokio I/O resources
-
async-utils
deleted - email help@crates.io to claim this crate name
-
futures-either
A way to await on the output of either of two futures