[][src]Struct tracing_futures::WithDispatch

pub struct WithDispatch<T> { /* fields omitted */ }

A future, stream, sink, or executor that has been instrumented with a tracing subscriber.

Methods

impl WithDispatch<Runtime>[src]

pub fn spawn<F>(&mut self, future: F) -> &mut Self where
    F: Future<Item = (), Error = ()> + Send + 'static, 
[src]

Spawn a future onto the Tokio runtime, in the context of this WithDispatch's trace dispatcher.

This spawns the given future onto the runtime's executor, usually a thread pool. The thread pool is then responsible for polling the future until it completes.

This method simply wraps a call to tokio::runtime::Runtime::spawn, instrumenting the spawned future beforehand.

pub fn block_on<F, R, E>(&mut self, future: F) -> Result<R, E> where
    F: Send + 'static + Future<Item = R, Error = E>,
    R: Send + 'static,
    E: Send + 'static, 
[src]

Run a future to completion on the Tokio runtime, in the context of this WithDispatch's trace dispatcher.

This runs the given future on the runtime, blocking until it is complete, and yielding its resolved result. Any tasks or timers which the future spawns internally will be executed on the runtime.

This method should not be called from an asynchronous context.

This method simply wraps a call to tokio::runtime::Runtime::block_on, instrumenting the spawned future beforehand.

Panics

This function panics if the executor is at capacity, if the provided future panics, or if called within an asynchronous execution context.

pub fn executor(&self) -> WithDispatch<TaskExecutor>[src]

Return a handle to the runtime's executor, in the context of this WithDispatch's trace dispatcher.

The returned handle can be used to spawn tasks that run on this runtime.

The instrumented handle functions identically to a tokio::runtime::TaskExecutor, but instruments the spawned futures prior to spawning them.

impl WithDispatch<Runtime>[src]

pub fn spawn<F>(&mut self, future: F) -> &mut Self where
    F: Future<Item = (), Error = ()> + 'static, 
[src]

Spawn a future onto the single-threaded Tokio runtime, in the context of this WithDispatch's trace dispatcher.

This method simply wraps a call to current_thread::Runtime::spawn, instrumenting the spawned future beforehand.

pub fn block_on<F, R, E>(&mut self, future: F) -> Result<R, E> where
    F: 'static + Future<Item = R, Error = E>,
    R: 'static,
    E: 'static, 
[src]

Runs the provided future in the context of this WithDispatch's trace dispatcher, blocking the current thread until the future completes.

This function can be used to synchronously block the current thread until the provided future has resolved either successfully or with an error. The result of the future is then returned from this function call.

Note that this function will also execute any spawned futures on the current thread, but will not block until these other spawned futures have completed. Once the function returns, any uncompleted futures remain pending in the Runtime instance. These futures will not run until block_on or run is called again.

The caller is responsible for ensuring that other spawned futures complete execution by calling block_on or run.

This method simply wraps a call to current_thread::Runtime::block_on, instrumenting the spawned future beforehand.

Panics

This function panics if the executor is at capacity, if the provided future panics, or if called within an asynchronous execution context.

pub fn handle(&self) -> WithDispatch<Handle>[src]

Get a new handle to spawn futures on the single-threaded Tokio runtime, in the context of this WithDispatch's trace dispatcher.

Different to the runtime itself, the handle can be sent to different threads.

The instrumented handle functions identically to a tokio::runtime::current_thread::Handle, but the spawned futures are run in the context of the trace dispatcher.

impl<T> WithDispatch<T>[src]

pub fn dispatch(&self) -> &Dispatch[src]

Borrows the Dispatch that this type is instrumented by.

pub fn into_inner(self) -> T[src]

Consumes the WithDispatch, returning the wrapped type.

Trait Implementations

impl<T: Clone> Clone for WithDispatch<T>[src]

fn clone_from(&mut self, source: &Self)1.0.0[src]

Performs copy-assignment from source. Read more

impl<T: Debug> Debug for WithDispatch<T>[src]

impl<T: Future> Future for WithDispatch<T>[src]

type Item = T::Item

The type of value that this future will resolved with if it is successful. Read more

type Error = T::Error

The type of error that this future will resolve with if it fails in a normal fashion. Read more

fn wait(self) -> Result<Self::Item, Self::Error>[src]

Block the current thread until this future is resolved. Read more

fn map<F, U>(self, f: F) -> Map<Self, F> where
    F: FnOnce(Self::Item) -> U, 
[src]

Map this future's result to a different type, returning a new future of the resulting type. Read more

fn map_err<F, E>(self, f: F) -> MapErr<Self, F> where
    F: FnOnce(Self::Error) -> E, 
[src]

Map this future's error to a different error, returning a new future. Read more

fn from_err<E>(self) -> FromErr<Self, E> where
    E: From<Self::Error>, 
[src]

Map this future's error to any error implementing From for this future's Error, returning a new future. Read more

fn then<F, B>(self, f: F) -> Then<Self, B, F> where
    B: IntoFuture,
    F: FnOnce(Result<Self::Item, Self::Error>) -> B, 
[src]

Chain on a computation for when a future finished, passing the result of the future to the provided closure f. Read more

fn and_then<F, B>(self, f: F) -> AndThen<Self, B, F> where
    B: IntoFuture<Error = Self::Error>,
    F: FnOnce(Self::Item) -> B, 
[src]

Execute another future after this one has resolved successfully. Read more

fn or_else<F, B>(self, f: F) -> OrElse<Self, B, F> where
    B: IntoFuture<Item = Self::Item>,
    F: FnOnce(Self::Error) -> B, 
[src]

Execute another future if this one resolves with an error. Read more

fn select<B>(self, other: B) -> Select<Self, <B as IntoFuture>::Future> where
    B: IntoFuture<Item = Self::Item, Error = Self::Error>, 
[src]

Waits for either one of two futures to complete. Read more

fn select2<B>(self, other: B) -> Select2<Self, <B as IntoFuture>::Future> where
    B: IntoFuture
[src]

Waits for either one of two differently-typed futures to complete. Read more

fn join<B>(self, other: B) -> Join<Self, <B as IntoFuture>::Future> where
    B: IntoFuture<Error = Self::Error>, 
[src]

Joins the result of two futures, waiting for them both to complete. Read more

fn join3<B, C>(
    self,
    b: B,
    c: C
) -> Join3<Self, <B as IntoFuture>::Future, <C as IntoFuture>::Future> where
    B: IntoFuture<Error = Self::Error>,
    C: IntoFuture<Error = Self::Error>, 
[src]

Same as join, but with more futures.

fn join4<B, C, D>(
    self,
    b: B,
    c: C,
    d: D
) -> Join4<Self, <B as IntoFuture>::Future, <C as IntoFuture>::Future, <D as IntoFuture>::Future> where
    B: IntoFuture<Error = Self::Error>,
    C: IntoFuture<Error = Self::Error>,
    D: IntoFuture<Error = Self::Error>, 
[src]

Same as join, but with more futures.

fn join5<B, C, D, E>(
    self,
    b: B,
    c: C,
    d: D,
    e: E
) -> Join5<Self, <B as IntoFuture>::Future, <C as IntoFuture>::Future, <D as IntoFuture>::Future, <E as IntoFuture>::Future> where
    B: IntoFuture<Error = Self::Error>,
    C: IntoFuture<Error = Self::Error>,
    D: IntoFuture<Error = Self::Error>,
    E: IntoFuture<Error = Self::Error>, 
[src]

Same as join, but with more futures.

fn into_stream(self) -> IntoStream<Self>[src]

Convert this future into a single element stream. Read more

fn flatten(self) -> Flatten<Self> where
    Self::Item: IntoFuture,
    <Self::Item as IntoFuture>::Error: From<Self::Error>, 
[src]

Flatten the execution of this future when the successful result of this future is itself another future. Read more

fn flatten_stream(self) -> FlattenStream<Self> where
    Self::Item: Stream,
    <Self::Item as Stream>::Error == Self::Error
[src]

Flatten the execution of this future when the successful result of this future is a stream. Read more

fn fuse(self) -> Fuse<Self>[src]

Fuse a future such that poll will never again be called once it has completed. Read more

fn inspect<F>(self, f: F) -> Inspect<Self, F> where
    F: FnOnce(&Self::Item), 
[src]

Do something with the item of a future, passing it on. Read more

fn catch_unwind(self) -> CatchUnwind<Self> where
    Self: UnwindSafe
[src]

Catches unwinding panics while polling the future. Read more

fn shared(self) -> Shared<Self>[src]

Create a cloneable handle to this future where all handles will resolve to the same result. Read more

impl<T, F> Executor<F> for WithDispatch<T> where
    T: Executor<WithDispatch<F>>,
    F: Future<Item = (), Error = ()>, 
[src]

impl<T> Executor for WithDispatch<T> where
    T: TokioExecutor
[src]

fn status(&self) -> Result<(), SpawnError>[src]

Provides a best effort hint to whether or not spawn will succeed. Read more

impl<T, F> TypedExecutor<F> for WithDispatch<T> where
    T: TypedExecutor<WithDispatch<F>>, 
[src]

Auto Trait Implementations

impl<T> Sync for WithDispatch<T> where
    T: Sync

impl<T> Send for WithDispatch<T> where
    T: Send

impl<T> Unpin for WithDispatch<T> where
    T: Unpin

impl<T> !RefUnwindSafe for WithDispatch<T>

impl<T> !UnwindSafe for WithDispatch<T>

Blanket Implementations

impl<T> Instrument for T[src]

fn instrument(self, span: Span) -> Instrumented<Self>[src]

Instruments this type with the provided Span, returning an Instrumented wrapper. Read more

impl<T> WithSubscriber for T[src]

fn with_subscriber<S>(self, subscriber: S) -> WithDispatch<Self> where
    S: Into<Dispatch>, 
[src]

Attaches the provided subscriber to this type, returning a WithDispatch wrapper. Read more

impl<T> ToOwned for T where
    T: Clone
[src]

type Owned = T

The resulting type after obtaining ownership.

impl<T> From<T> for T[src]

impl<T, U> Into<U> for T where
    U: From<T>, 
[src]

impl<T, U> TryFrom<U> for T where
    U: Into<T>, 
[src]

type Error = Infallible

The type returned in the event of a conversion error.

impl<T, U> TryInto<U> for T where
    U: TryFrom<T>, 
[src]

type Error = <U as TryFrom<T>>::Error

The type returned in the event of a conversion error.

impl<T> BorrowMut<T> for T where
    T: ?Sized
[src]

impl<T> Borrow<T> for T where
    T: ?Sized
[src]

impl<T> Any for T where
    T: 'static + ?Sized
[src]

impl<F> IntoFuture for F where
    F: Future
[src]

type Future = F

The future that this type can be converted into.

type Item = <F as Future>::Item

The item that the future may resolve with.

type Error = <F as Future>::Error

The error that the future may resolve with.

impl<T> FutureExt for T where
    T: Future + ?Sized
[src]

fn timeout(self, timeout: Duration) -> Timeout<Self>[src]

Creates a new future which allows self until timeout. Read more

impl<T> Erased for T