mirror of
https://github.com/hl-archive-node/nanoreth.git
synced 2025-12-06 10:59:55 +00:00
chore(task): move blocking pool to reth-tasks (#6929)
This commit is contained in:
@ -27,5 +27,12 @@ tracing.workspace = true
|
||||
thiserror.workspace = true
|
||||
dyn-clone = "1.0"
|
||||
|
||||
# feature `rayon`
|
||||
rayon = { workspace = true, optional = true }
|
||||
pin-project = { workspace = true, optional = true }
|
||||
|
||||
[dev-dependencies]
|
||||
tokio = { workspace = true, features = ["sync", "rt", "rt-multi-thread", "time", "macros"] }
|
||||
|
||||
[features]
|
||||
rayon = ["dep:rayon", "pin-project"]
|
||||
|
||||
@ -1,4 +1,8 @@
|
||||
//! Reth task management.
|
||||
//!
|
||||
//! # Feature Flags
|
||||
//!
|
||||
//! - `rayon`: Enable rayon thread pool for blocking tasks.
|
||||
|
||||
#![doc(
|
||||
html_logo_url = "https://raw.githubusercontent.com/paradigmxyz/reth/main/assets/reth-docs.png",
|
||||
@ -38,6 +42,9 @@ use tracing_futures::Instrument;
|
||||
pub mod metrics;
|
||||
pub mod shutdown;
|
||||
|
||||
#[cfg(feature = "rayon")]
|
||||
pub mod pool;
|
||||
|
||||
/// A type that can spawn tasks.
|
||||
///
|
||||
/// The main purpose of this type is to abstract over [TaskExecutor] so it's more convenient to
|
||||
|
||||
173
crates/tasks/src/pool.rs
Normal file
173
crates/tasks/src/pool.rs
Normal file
@ -0,0 +1,173 @@
|
||||
//! Additional helpers for executing tracing calls
|
||||
|
||||
use std::{
|
||||
future::Future,
|
||||
panic::{catch_unwind, AssertUnwindSafe},
|
||||
pin::Pin,
|
||||
sync::Arc,
|
||||
task::{ready, Context, Poll},
|
||||
thread,
|
||||
};
|
||||
use tokio::sync::{oneshot, AcquireError, OwnedSemaphorePermit, Semaphore};
|
||||
|
||||
/// RPC Tracing call guard semaphore.
|
||||
///
|
||||
/// This is used to restrict the number of concurrent RPC requests to tracing methods like
|
||||
/// `debug_traceTransaction` as well as `eth_getProof` because they can consume a lot of
|
||||
/// memory and CPU.
|
||||
///
|
||||
/// This types serves as an entry guard for the [BlockingTaskPool] and is used to rate limit
|
||||
/// parallel blocking tasks in the pool.
|
||||
#[derive(Clone, Debug)]
|
||||
pub struct BlockingTaskGuard(Arc<Semaphore>);
|
||||
|
||||
impl BlockingTaskGuard {
|
||||
/// Create a new `BlockingTaskGuard` with the given maximum number of blocking tasks in
|
||||
/// parallel.
|
||||
pub fn new(max_blocking_tasks: u32) -> Self {
|
||||
Self(Arc::new(Semaphore::new(max_blocking_tasks as usize)))
|
||||
}
|
||||
|
||||
/// See also [Semaphore::acquire_owned]
|
||||
pub async fn acquire_owned(self) -> Result<OwnedSemaphorePermit, AcquireError> {
|
||||
self.0.acquire_owned().await
|
||||
}
|
||||
|
||||
/// See also [Semaphore::acquire_many_owned]
|
||||
pub async fn acquire_many_owned(self, n: u32) -> Result<OwnedSemaphorePermit, AcquireError> {
|
||||
self.0.acquire_many_owned(n).await
|
||||
}
|
||||
}
|
||||
|
||||
/// Used to execute blocking tasks on a rayon threadpool from within a tokio runtime.
|
||||
///
|
||||
/// This is a dedicated threadpool for blocking tasks which are CPU bound.
|
||||
/// RPC calls that perform blocking IO (disk lookups) are not executed on this pool but on the tokio
|
||||
/// runtime's blocking pool, which performs poorly with CPU bound tasks. Once the tokio blocking
|
||||
/// pool is saturated it is converted into a queue, blocking tasks could then interfere with the
|
||||
/// queue and block other RPC calls.
|
||||
///
|
||||
/// See also [tokio-docs] for more information.
|
||||
///
|
||||
/// [tokio-docs]: https://docs.rs/tokio/latest/tokio/index.html#cpu-bound-tasks-and-blocking-code
|
||||
#[derive(Clone, Debug)]
|
||||
pub struct BlockingTaskPool {
|
||||
pool: Arc<rayon::ThreadPool>,
|
||||
}
|
||||
|
||||
impl BlockingTaskPool {
|
||||
/// Create a new `BlockingTaskPool` with the given threadpool.
|
||||
pub fn new(pool: rayon::ThreadPool) -> Self {
|
||||
Self { pool: Arc::new(pool) }
|
||||
}
|
||||
|
||||
/// Convenience function to start building a new threadpool.
|
||||
pub fn builder() -> rayon::ThreadPoolBuilder {
|
||||
rayon::ThreadPoolBuilder::new()
|
||||
}
|
||||
|
||||
/// Convenience function to build a new threadpool with the default configuration.
|
||||
///
|
||||
/// Uses [`rayon::ThreadPoolBuilder::build`](rayon::ThreadPoolBuilder::build) defaults but
|
||||
/// increases the stack size to 8MB.
|
||||
pub fn build() -> Result<Self, rayon::ThreadPoolBuildError> {
|
||||
Self::builder().build().map(Self::new)
|
||||
}
|
||||
|
||||
/// Asynchronous wrapper around Rayon's
|
||||
/// [`ThreadPool::spawn`](rayon::ThreadPool::spawn).
|
||||
///
|
||||
/// Runs a function on the configured threadpool, returning a future that resolves with the
|
||||
/// function's return value.
|
||||
///
|
||||
/// If the function panics, the future will resolve to an error.
|
||||
pub fn spawn<F, R>(&self, func: F) -> BlockingTaskHandle<R>
|
||||
where
|
||||
F: FnOnce() -> R + Send + 'static,
|
||||
R: Send + 'static,
|
||||
{
|
||||
let (tx, rx) = oneshot::channel();
|
||||
|
||||
self.pool.spawn(move || {
|
||||
let _result = tx.send(catch_unwind(AssertUnwindSafe(func)));
|
||||
});
|
||||
|
||||
BlockingTaskHandle { rx }
|
||||
}
|
||||
|
||||
/// Asynchronous wrapper around Rayon's
|
||||
/// [`ThreadPool::spawn_fifo`](rayon::ThreadPool::spawn_fifo).
|
||||
///
|
||||
/// Runs a function on the configured threadpool, returning a future that resolves with the
|
||||
/// function's return value.
|
||||
///
|
||||
/// If the function panics, the future will resolve to an error.
|
||||
pub fn spawn_fifo<F, R>(&self, func: F) -> BlockingTaskHandle<R>
|
||||
where
|
||||
F: FnOnce() -> R + Send + 'static,
|
||||
R: Send + 'static,
|
||||
{
|
||||
let (tx, rx) = oneshot::channel();
|
||||
|
||||
self.pool.spawn_fifo(move || {
|
||||
let _result = tx.send(catch_unwind(AssertUnwindSafe(func)));
|
||||
});
|
||||
|
||||
BlockingTaskHandle { rx }
|
||||
}
|
||||
}
|
||||
|
||||
/// Async handle for a blocking task running in a Rayon thread pool.
|
||||
///
|
||||
/// ## Panics
|
||||
///
|
||||
/// If polled from outside a tokio runtime.
|
||||
#[derive(Debug)]
|
||||
#[must_use = "futures do nothing unless you `.await` or poll them"]
|
||||
#[pin_project::pin_project]
|
||||
pub struct BlockingTaskHandle<T> {
|
||||
#[pin]
|
||||
pub(crate) rx: oneshot::Receiver<thread::Result<T>>,
|
||||
}
|
||||
|
||||
impl<T> Future for BlockingTaskHandle<T> {
|
||||
type Output = thread::Result<T>;
|
||||
|
||||
fn poll(self: Pin<&mut Self>, cx: &mut Context<'_>) -> Poll<Self::Output> {
|
||||
match ready!(self.project().rx.poll(cx)) {
|
||||
Ok(res) => Poll::Ready(res),
|
||||
Err(_) => Poll::Ready(Err(Box::<TokioBlockingTaskError>::default())),
|
||||
}
|
||||
}
|
||||
}
|
||||
|
||||
/// An error returned when the Tokio channel is dropped while awaiting a result.
|
||||
///
|
||||
/// This should only happen
|
||||
#[derive(Debug, Default, thiserror::Error)]
|
||||
#[error("tokio channel dropped while awaiting result")]
|
||||
#[non_exhaustive]
|
||||
pub struct TokioBlockingTaskError;
|
||||
|
||||
#[cfg(test)]
|
||||
mod tests {
|
||||
use super::*;
|
||||
|
||||
#[tokio::test]
|
||||
async fn blocking_pool() {
|
||||
let pool = BlockingTaskPool::build().unwrap();
|
||||
let res = pool.spawn(move || 5);
|
||||
let res = res.await.unwrap();
|
||||
assert_eq!(res, 5);
|
||||
}
|
||||
|
||||
#[tokio::test]
|
||||
async fn blocking_pool_panic() {
|
||||
let pool = BlockingTaskPool::build().unwrap();
|
||||
let res = pool.spawn(move || -> i32 {
|
||||
panic!();
|
||||
});
|
||||
let res = res.await;
|
||||
assert!(res.is_err());
|
||||
}
|
||||
}
|
||||
Reference in New Issue
Block a user