-
event-listener
Notify async tasks or threads
-
async-task
Task abstraction for building executors
-
futures-task
Tools for working with tasks
-
tokio-metrics
Runtime and task level metrics for Tokio applications
-
async-global-executor
A global executor built on top of async-executor and async-io
-
prodash
A dashboard for visualizing progress of asynchronous and possibly blocking tasks
-
diatomic-waker
An async, lock-free synchronization primitive for task wakeup
-
embassy-executor
async/await executor designed for embedded usage
-
atomic-waker
A synchronization primitive for task wakeup
-
tokio_with_wasm
Mimicking tokio functionalities on web browsers
-
tokio-console
The Tokio console: a debugger for async Rust
-
async-shutdown
one-stop solution for async graceful shutdown
-
async-backtrace
Efficient, logical 'backtraces' of async tasks
-
async-condvar-fair
Condition variables for async Rust
-
futures-executor
Executors for asynchronous tasks based on the futures-rs library
-
async-dup
Duplicate an async I/O handle
-
tokio_schedule
schedule tasks in tokio runtime
-
celery
Rust implementation of Celery
-
zng
Cross-platform GUI framework
-
fang
Background job processing library for Rust
-
bevy_defer
asynchronous runtime for executing async coroutines
-
delay_timer
Time-manager of delayed tasks. Like crontab, but synchronous asynchronous tasks are possible, and dynamic add/cancel/remove is supported.
-
local-waker
A synchronization primitive for thread-local task wakeup
-
any_spawner
Spawn asynchronous tasks in an executor-independent way
-
lilos
A tiny embedded OS based around Futures and async
-
bevy_tasks
A task executor for Bevy Engine
-
bevy-tokio-tasks
integration of a Tokio runtime into a Bevy app for background processing
-
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…
-
bevy-async-ecs
Asynchronous interface for Bevy ECS
-
yazi-scheduler
Yazi task scheduler
-
bevy_async_task
Ergonomic abstractions to async programming in Bevy
-
rat-salsa
ratatui widgets and a crossterm event-loop
-
tasklet
An asynchronous task scheduling library
-
stop-token
Experimental cooperative cancellation for async Rust
-
tsuki-scheduler
light wight, composable and extensible scheduler for every runtime
-
await-tree
Instrument await-tree for actor-based applications
-
sacs
Async Cron Scheduler for Tokio
-
singleflight-async
Singleflight in async style
-
cassette
single-future, non-blocking executor intended for building state machines
-
spawns
Async runtime agnostic thread context task spawner for Rust
-
trale
minimalistic Rust async executor using io_uring for efficient, correct task execution
-
tasky
fluent async task experiments
-
hooch
A small async runtime that's been bootlegged for my projects
-
yield-progress
Combined progress reporting and cooperative task yielding
-
winmsg-executor
Per-thread async rust executor for windows
-
clokwerk
recurring task scheduler, similar to Python's schedule
-
bevy_cached_query
high level query library for Bevy based on async tasks and Observer API very loosely inspired by TanStack Query
-
async-observable
Async & reactive synchronization model to keep multiple async tasks / threads partially synchronized
-
skedgy
asynchronous job scheduler
-
taskmanager
Manage groups of background tasks
-
tokio-tasks
Task managment for tokio
-
backie
Background task processing for Rust applications with Tokio, Diesel, and PostgreSQL
-
exo_task
A lightweight async task executor for bare metal (or any) systems
-
smolscale
A high-performance async-task scheduler
-
ptask
Spawning parasitic tasks
-
async_tasks_recorder
A struct for recording execution status of async tasks with async methods
-
task_scheduler_rs
A Rust-based scheduler with basic functionality, focused on adding tasks and handling actions like execute, pause, and shutdown using channels for task communication
-
async_timing_util
tokio async functions for waiting until even intervals (on 1 min, 5 min, 30 min, etc), or waiting until a specified timestamp
-
tokio-task-tracker
graceful shutdown solution for tokio
-
fibers
execute a number of lightweight asynchronous tasks (a.k.a, fibers) based on futures and mio
-
parallel-future
fluent async task experiments
-
interruptible_polling
General purpose polling tasks with RAII-driven fast clean exits
-
safina-executor
Safe async runtime executor - ARCHIVED: Code moved to
safina
crate -
waitgroup
Async waitgroup for a collection of task to finish
-
vexide-async
The async executor at the core of vexide
-
retainer
Minimal async cache in Rust with support for key expirations
-
tasc
A minimnal, asynchronous threadpool
-
task-group
manage groups of tokio tasks
-
smolscale2
hitdns fork of original smolscale
-
graphile_worker
High performance Rust/PostgreSQL job queue (also suitable for getting jobs generated by PostgreSQL triggers/functions out into a different work queue)
-
async_tasks_state_map
A struct for recording execution status of async tasks with async methods
-
lilos-handoff
Synchronous rendezvous structure for lilos
-
safina-sync
Safe structs for sharing or sending data between async tasks - ARCHIVED: Code moved to
safina
crate -
zng-task
Part of the zng project
-
async_progress
Create sync points across async tasks
-
puff-rs
Puff - Deep Stack Python Runtime and GraphQL library
-
mini-tokio
basic asynchronous rust executor
-
night
A scalable Task Queue for executing asynchronous tasks in topological order
-
safina-async-test
Macro for running async tests - ARCHIVED: Code moved to
safina
crate -
elf_utils
elf_rust utils
-
taski
async task DAG execution
-
workflow-task
-
peachy
async task manager, similar to thread pool but cooler and for structs
-
awaitgroup
Wait for a collection of async tasks to finish
-
steward
Task runner and process manager for Rust
-
wasm-rs-async-executor
Async executor for WebAssembly
-
hds_tokio-console
test crate, do not use
-
lifeline
dependency injection library for asynchronous message-based applications
-
task-exec-queue
A asynchronous task execution queue
-
grizzly_scheduler
A scheduler for running async tasks using cron expressions. It is built on top of tokio. Tasks can be parallel or sequential. Fuzzy random offset can be added to the cron expression.
-
priority
A thread/task priority type
-
rexecutor
A robust job processing library
-
async-pipes
building concurrent data processing pipelines
-
async-dispatcher
async runtime based on a pluggable dispatcher
-
wasm-futures-executor
Executor for asynchronous task based on wasm web workers
-
threadfin
A thread pool for running multiple tasks on a configurable group of threads
-
async-cpupool
async threadpool for CPU-bound tasks
-
async-throttle
Asynchronous Rate Limiting
-
cosync
a single threaded, sequential, parameterized task pool for games
-
rdcache
cache using redis backend
-
bevy_mod_async
Ergonomic async tasks plugin for the Bevy game engine
-
woke
A minimalistic waker implementation for executors
-
async-cron-scheduler
Runtime-agnostic async task scheduler with cron expression support
-
chord-core
async parallel case executor
-
wait-for-me
Async CountDownLatch
-
tokio-context
Contexts for cancelling asynchronous tasks using tokio
-
tophat
A small, pragmatic, and flexible async http server
-
minimal-executor
A minimal executor for asynchronous tasks based on the futures-rs library
-
task-stream
a global task executor, run in
no_std
-
minactor
Minimal actor framework for Rust with tokio
-
spawns-compat
Async runtime detections for thread context task spawner
-
task-notify
Notify async tasks when someone mutates data they're interested in
-
waitlist
Keep track of an ordered list of Wakers to wake
-
async-events
Waiting for external task completion in asynchronous Rust code
-
killswitch
used to broadcast a shutdown request
-
aiur
Single threaded async executor with structured concurrency
-
scoped_spawn
Full structured concurrency for asynchronous programming
-
smartpoll
A 'Task' abstraction that simplifies polling futures
-
trace-tools
Tracing and diagnostic tools for tasks
-
async_dag
An async task scheduling utilitiy
-
tokio-task-pool
Task pool for Tokio Runtime
-
switchyard
Real-time compute focused async executor
-
telecomande
A small crate providing a primitive for the execution of asynchronous tasks by processor through commands
-
juggle
Async task switching for cooperative multitasking in single thread environments with no_std support
-
sched-callback
async callback scheduling
-
agnostic_async_executor
Agnostic Rust Async Executor
-
queued-task
concurrent queue task processing
-
crb-task
CRB | Composable Runtime Blocks | Task
-
spawns-executor
Async executors for thread context task spawner
-
tokio-tasker
Lets you stop and join groups of Tokio tasks
-
async_job
async cron job crate for Rust
-
extern_executor
Async executor which delegates futures polling to external event-loop
-
rasks
Scheduled background tasks
-
async_wasm_task
Manage the concurrency of async tasks in webassembly Rust
-
moosicbox_task
MoosicBox task utilities package
-
one_for_one
supervize spawn'ed async tasks
-
async-spin-sleep
providing a highly accurate asynchronous timer for multiple async tasks using spin sleep in a single thread
-
tokio_tasks_shutdown
Easily manage and gracefully shutdown tokio tasks while monitoring their return results
-
async-task-group
Manage groups of
async-std
tasks as a single unit -
tokio-async-utils
Async utils such as TaskHandle type that aborts task on handle drop
-
embedded-trace
A Future tracing utility for embedded systems
-
futures-executor-preview
Executors for asynchronous tasks based on the futures-rs library
-
chex
Global exit signal library
-
chord-cli
async parallel case executor
-
tokio-inherit-task-local
Task local variables for tokio that can be inherited across a spawn
-
pausable_future
Pausable and resumable future, useful in background tasks
-
waker-waiter
async runtimes interoperate with arbitrary futures
-
pandet
A lightweight library to help act on panics of detached async tasks
-
egui_task_manager
Manage asynchronous easily
-
microasync
Very small async runner
-
tasktrace
Logical 'backtraces' of async tasks
-
rider
bounded executor for tokio; limit the count of tasks running 🚦
-
rework
Multi-threaded task processing in the Master-Worker pattern
-
taskwait
Runtime agnostic way to wait for a group of async tasks
-
arl
A rate limiter to be used with tokio
-
job-dispatcher
execute jobs in an async way
-
atex
Lib for async local task evaluation(sqlite or in-memory)
-
diath
light-weight library for communication between tokio async tasks
-
async-raft2
An async implementation of the Raft distributed consensus protocol
-
sigfinn
Lifecycle manager for spawning tasks
-
name_locker
interface for asynchronous name lockers, that can run an async task with lock on a given name
-
windowed-futures
Helpers for windowed parallel execution of collections of futures
-
async-task-executor
A lightweight Rust library for building extensible asynchronous task executors, designed for handling large-scale multitasking in server environments
-
waitout
Awaits the completion of multiple async tasks
Try searching with DuckDuckGo.