[−][src]Trait tokio::prelude::Future  
Trait for types which are a placeholder of a value that may become available at some later point in time.
In addition to the documentation here you can also find more information about futures online at https://tokio.rs
Futures are used to provide a sentinel through which a value can be referenced. They crucially allow chaining and composing operations through consumption which allows expressing entire trees of computation as one sentinel value.
The ergonomics and implementation of the Future trait are very similar to
the Iterator trait in that there is just one methods you need
to implement, but you get a whole lot of others for free as a result.
The poll method
The core method of future, poll, is used to attempt to generate the value
of a Future. This method does not block but is allowed to inform the
caller that the value is not ready yet. Implementations of poll may
themselves do work to generate the value, but it's guaranteed that this will
never block the calling thread.
A key aspect of this method is that if the value is not yet available the current task is scheduled to receive a notification when it's later ready to be made available. This follows what's typically known as a "readiness" or "pull" model where values are pulled out of futures on demand, and otherwise a task is notified when a value might be ready to get pulled out.
The poll method is not intended to be called in general, but rather is
typically called in the context of a "task" which drives a future to
completion. For more information on this see the task module.
More information about the details of poll and the nitty-gritty of tasks
can be found online at tokio.rs.
Combinators
Like iterators, futures provide a large number of combinators to work with
futures to express computations in a much more natural method than
scheduling a number of callbacks. For example the map method can change
a Future<Item=T> to a Future<Item=U> or an and_then combinator could
create a future after the first one is done and only be resolved when the
second is done.
Combinators act very similarly to the methods on the Iterator trait itself
or those on Option and Result. Like with iterators, the combinators are
zero-cost and don't impose any extra layers of indirection you wouldn't
otherwise have to write down.
More information about combinators can be found on tokio.rs.
Associated Types
type Item
The type of value that this future will resolved with if it is successful.
type Error
The type of error that this future will resolve with if it fails in a normal fashion.
Required methods
fn poll(&mut self) -> Result<Async<Self::Item>, Self::Error>
Query this future to see if its value has become available, registering interest if it is not.
This function will check the internal state of the future and assess whether the value is ready to be produced. Implementers of this function should ensure that a call to this never blocks as event loops may not work properly otherwise.
When a future is not ready yet, the Async::NotReady value will be
returned. In this situation the future will also register interest of
the current task in the value being produced. This is done by calling
task::park to retrieve a handle to the current Task. When the future
is then ready to make progress (e.g. it should be polled again) the
unpark method is called on the Task.
More information about the details of poll and the nitty-gritty of
tasks can be found online at tokio.rs.
Runtime characteristics
This function, poll, is the primary method for 'making progress'
within a tree of futures. For example this method will be called
repeatedly as the internal state machine makes its various transitions.
Executors are responsible for ensuring that this function is called in
the right location (e.g. always on an I/O thread or not). Unless it is
otherwise arranged to be so, it should be ensured that implementations
of this function finish very quickly.
Returning quickly prevents unnecessarily clogging up threads and/or
event loops while a poll function call, for example, takes up compute
resources to perform some expensive computation. If it is known ahead
of time that a call to poll may end up taking awhile, the work should
be offloaded to a thread pool (or something similar) to ensure that
poll can return quickly.
Note that the poll function is not called repeatedly in a loop for
futures typically, but only whenever the future itself is ready. If
you're familiar with the poll(2) or select(2) syscalls on Unix
it's worth noting that futures typically do not suffer the same
problems of "all wakeups must poll all events". Futures have enough
support for only polling futures which cause a wakeup.
Return value
This function returns Async::NotReady if the future is not ready yet,
Err if the future is finished but resolved to an error, or
Async::Ready with the result of this future if it's finished
successfully. Once a future has finished it is considered a contract
error to continue polling the future.
If NotReady is returned, then the future will internally register
interest in the value being produced for the current task (through
task::park). In other words, the current task will receive a
notification (through the unpark method) once the value is ready to be
produced or the future can make progress.
Note that if NotReady is returned it only means that this task will
receive a notification. Historical calls to poll with different tasks
will not receive notifications. In other words, implementers of the
Future trait need not store a queue of tasks to notify, but only the
last task that called this method. Alternatively callers of this method
can only rely on the most recent task which call poll being notified
when a future is ready.
Panics
Once a future has completed (returned Ready or Err from poll),
then any future calls to poll may panic, block forever, or otherwise
cause wrong behavior. The Future trait itself provides no guarantees
about the behavior of poll after a future has completed.
Callers who may call poll too many times may want to consider using
the fuse adaptor which defines the behavior of poll, but comes with
a little bit of extra cost.
Additionally, calls to poll must always be made from within the
context of a task. If a current task is not set then this method will
likely panic.
Errors
This future may have failed to finish the computation, in which case
the Err variant will be returned with an appropriate payload of an
error.
Provided methods
fn wait(self) -> Result<Self::Item, Self::Error>
Block the current thread until this future is resolved.
This method will consume ownership of this future, driving it to
completion via poll and blocking the current thread while it's waiting
for the value to become available. Once the future is resolved the
result of this future is returned.
Note: This method is not appropriate to call on event loops or similar I/O situations because it will prevent the event loop from making progress (this blocks the thread). This method should only be called when it's guaranteed that the blocking work associated with this future will be completed by another thread.
This method is only available when the use_std feature of this
library is activated, and it is activated by default.
Panics
This function does not attempt to catch panics. If the poll function
of this future panics, panics will be propagated to the caller.
fn map<F, U>(self, f: F) -> Map<Self, F> where
    F: FnOnce(Self::Item) -> U, 
F: FnOnce(Self::Item) -> U,
Map this future's result to a different type, returning a new future of the resulting type.
This function is similar to the Option::map or Iterator::map where
it will change the type of the underlying future. This is useful to
chain along a computation once a future has been resolved.
The closure provided will only be called if this future is resolved successfully. If this future returns an error, panics, or is dropped, then the closure provided will never be invoked.
Note that this function consumes the receiving future and returns a
wrapped version of it, similar to the existing map methods in the
standard library.
Examples
use futures::prelude::*; use futures::future; let future = future::ok::<u32, u32>(1); let new_future = future.map(|x| x + 3); assert_eq!(new_future.wait(), Ok(4));
Calling map on an errored Future has no effect:
use futures::prelude::*; use futures::future; let future = future::err::<u32, u32>(1); let new_future = future.map(|x| x + 3); assert_eq!(new_future.wait(), Err(1));
fn map_err<F, E>(self, f: F) -> MapErr<Self, F> where
    F: FnOnce(Self::Error) -> E, 
F: FnOnce(Self::Error) -> E,
Map this future's error to a different error, returning a new future.
This function is similar to the Result::map_err where it will change
the error type of the underlying future. This is useful for example to
ensure that futures have the same error type when used with combinators
like select and join.
The closure provided will only be called if this future is resolved with an error. If this future returns a success, panics, or is dropped, then the closure provided will never be invoked.
Note that this function consumes the receiving future and returns a wrapped version of it.
Examples
use futures::future::*; let future = err::<u32, u32>(1); let new_future = future.map_err(|x| x + 3); assert_eq!(new_future.wait(), Err(4));
Calling map_err on a successful Future has no effect:
use futures::future::*; let future = ok::<u32, u32>(1); let new_future = future.map_err(|x| x + 3); assert_eq!(new_future.wait(), Ok(1));
fn from_err<E>(self) -> FromErr<Self, E> where
    E: From<Self::Error>, 
E: From<Self::Error>,
Map this future's error to any error implementing From for
this future's Error, returning a new future.
This function does for futures what try! does for Result,
by letting the compiler infer the type of the resulting error.
Just as map_err above, this is useful for example to ensure
that futures have the same error type when used with
combinators like select and join.
Note that this function consumes the receiving future and returns a wrapped version of it.
Examples
use futures::prelude::*; use futures::future; let future_with_err_u8 = future::err::<(), u8>(1); let future_with_err_u32 = future_with_err_u8.from_err::<u32>();
fn then<F, B>(self, f: F) -> Then<Self, B, F> where
    B: IntoFuture,
    F: FnOnce(Result<Self::Item, Self::Error>) -> B, 
B: IntoFuture,
F: FnOnce(Result<Self::Item, Self::Error>) -> B,
Chain on a computation for when a future finished, passing the result of
the future to the provided closure f.
This function can be used to ensure a computation runs regardless of
the conclusion of the future. The closure provided will be yielded a
Result once the future is complete.
The returned value of the closure must implement the IntoFuture trait
and can represent some more work to be done before the composed future
is finished. Note that the Result type implements the IntoFuture
trait so it is possible to simply alter the Result yielded to the
closure and return it.
If this future is dropped or panics then the closure f will not be
run.
Note that this function consumes the receiving future and returns a wrapped version of it.
Examples
use futures::prelude::*; use futures::future; let future_of_1 = future::ok::<u32, u32>(1); let future_of_4 = future_of_1.then(|x| { x.map(|y| y + 3) }); let future_of_err_1 = future::err::<u32, u32>(1); let future_of_4 = future_of_err_1.then(|x| { match x { Ok(_) => panic!("expected an error"), Err(y) => future::ok::<u32, u32>(y + 3), } });
fn and_then<F, B>(self, f: F) -> AndThen<Self, B, F> where
    B: IntoFuture<Error = Self::Error>,
    F: FnOnce(Self::Item) -> B, 
B: IntoFuture<Error = Self::Error>,
F: FnOnce(Self::Item) -> B,
Execute another future after this one has resolved successfully.
This function can be used to chain two futures together and ensure that the final future isn't resolved until both have finished. The closure provided is yielded the successful result of this future and returns another value which can be converted into a future.
Note that because Result implements the IntoFuture trait this method
can also be useful for chaining fallible and serial computations onto
the end of one future.
If this future is dropped, panics, or completes with an error then the
provided closure f is never called.
Note that this function consumes the receiving future and returns a wrapped version of it.
Examples
use futures::prelude::*; use futures::future::{self, FutureResult}; let future_of_1 = future::ok::<u32, u32>(1); let future_of_4 = future_of_1.and_then(|x| { Ok(x + 3) }); let future_of_err_1 = future::err::<u32, u32>(1); future_of_err_1.and_then(|_| -> FutureResult<u32, u32> { panic!("should not be called in case of an error"); });
fn or_else<F, B>(self, f: F) -> OrElse<Self, B, F> where
    B: IntoFuture<Item = Self::Item>,
    F: FnOnce(Self::Error) -> B, 
B: IntoFuture<Item = Self::Item>,
F: FnOnce(Self::Error) -> B,
Execute another future if this one resolves with an error.
Return a future that passes along this future's value if it succeeds,
and otherwise passes the error to the closure f and waits for the
future it returns. The closure may also simply return a value that can
be converted into a future.
Note that because Result implements the IntoFuture trait this method
can also be useful for chaining together fallback computations, where
when one fails, the next is attempted.
If this future is dropped, panics, or completes successfully then the
provided closure f is never called.
Note that this function consumes the receiving future and returns a wrapped version of it.
Examples
use futures::prelude::*; use futures::future::{self, FutureResult}; let future_of_err_1 = future::err::<u32, u32>(1); let future_of_4 = future_of_err_1.or_else(|x| -> Result<u32, u32> { Ok(x + 3) }); let future_of_1 = future::ok::<u32, u32>(1); future_of_1.or_else(|_| -> FutureResult<u32, u32> { panic!("should not be called in case of success"); });
fn select<B>(self, other: B) -> Select<Self, <B as IntoFuture>::Future> where
    B: IntoFuture<Item = Self::Item, Error = Self::Error>, 
B: IntoFuture<Item = Self::Item, Error = Self::Error>,
Waits for either one of two futures to complete.
This function will return a new future which awaits for either this or
the other future to complete. The returned future will finish with
both the value resolved and a future representing the completion of the
other work. Both futures must have the same item and error type.
Note that this function consumes the receiving futures and returns a wrapped version of them.
Examples
use futures::prelude::*; use futures::future; use std::thread; use std::time; let future1 = future::lazy(|| { thread::sleep(time::Duration::from_secs(5)); future::ok::<char, ()>('a') }); let future2 = future::lazy(|| { thread::sleep(time::Duration::from_secs(3)); future::ok::<char, ()>('b') }); let (value, last_future) = future1.select(future2).wait().ok().unwrap(); assert_eq!(value, 'a'); assert_eq!(last_future.wait().unwrap(), 'b');
A poor-man's join implemented on top of select:
use futures::prelude::*; use futures::future; fn join<A>(a: A, b: A) -> Box<Future<Item=(u32, u32), Error=u32>> where A: Future<Item = u32, Error = u32> + 'static, { Box::new(a.select(b).then(|res| -> Box<Future<Item=_, Error=_>> { match res { Ok((a, b)) => Box::new(b.map(move |b| (a, b))), Err((a, _)) => Box::new(future::err(a)), } })) }
fn select2<B>(self, other: B) -> Select2<Self, <B as IntoFuture>::Future> where
    B: IntoFuture, 
B: IntoFuture,
Waits for either one of two differently-typed futures to complete.
This function will return a new future which awaits for either this or
the other future to complete. The returned future will finish with
both the value resolved and a future representing the completion of the
other work.
Note that this function consumes the receiving futures and returns a wrapped version of them.
Also note that if both this and the second future have the same
success/error type you can use the Either::split method to
conveniently extract out the value at the end.
Examples
use futures::prelude::*; use futures::future::{self, Either}; // A poor-man's join implemented on top of select2 fn join<A, B, E>(a: A, b: B) -> Box<Future<Item=(A::Item, B::Item), Error=E>> where A: Future<Error = E> + 'static, B: Future<Error = E> + 'static, E: 'static, { Box::new(a.select2(b).then(|res| -> Box<Future<Item=_, Error=_>> { match res { Ok(Either::A((x, b))) => Box::new(b.map(move |y| (x, y))), Ok(Either::B((y, a))) => Box::new(a.map(move |x| (x, y))), Err(Either::A((e, _))) => Box::new(future::err(e)), Err(Either::B((e, _))) => Box::new(future::err(e)), } })) }
fn join<B>(self, other: B) -> Join<Self, <B as IntoFuture>::Future> where
    B: IntoFuture<Error = Self::Error>, 
B: IntoFuture<Error = Self::Error>,
Joins the result of two futures, waiting for them both to complete.
This function will return a new future which awaits both this and the
other future to complete. The returned future will finish with a tuple
of both results.
Both futures must have the same error type, and if either finishes with an error then the other will be dropped and that error will be returned.
Note that this function consumes the receiving future and returns a wrapped version of it.
Examples
use futures::prelude::*; use futures::future; let a = future::ok::<u32, u32>(1); let b = future::ok::<u32, u32>(2); let pair = a.join(b); assert_eq!(pair.wait(), Ok((1, 2)));
If one or both of the joined Futures is errored, the resulting
Future will be errored:
use futures::prelude::*; use futures::future; let a = future::ok::<u32, u32>(1); let b = future::err::<u32, u32>(2); let pair = a.join(b); assert_eq!(pair.wait(), Err(2));
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>, 
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>,
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>, 
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>,
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>, 
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>,
Same as join, but with more futures.
fn into_stream(self) -> IntoStream<Self>
Convert this future into a single element stream.
The returned stream contains single success if this future resolves to success or single error if this future resolves into error.
Examples
use futures::prelude::*; use futures::future; let future = future::ok::<_, bool>(17); let mut stream = future.into_stream(); assert_eq!(Ok(Async::Ready(Some(17))), stream.poll()); assert_eq!(Ok(Async::Ready(None)), stream.poll()); let future = future::err::<bool, _>(19); let mut stream = future.into_stream(); assert_eq!(Err(19), stream.poll()); assert_eq!(Ok(Async::Ready(None)), stream.poll());
fn flatten(self) -> Flatten<Self> where
    Self::Item: IntoFuture,
    <Self::Item as IntoFuture>::Error: From<Self::Error>, 
Self::Item: IntoFuture,
<Self::Item as IntoFuture>::Error: From<Self::Error>,
Flatten the execution of this future when the successful result of this future is itself another future.
This can be useful when combining futures together to flatten the
computation out the final result. This method can only be called
when the successful result of this future itself implements the
IntoFuture trait and the error can be created from this future's error
type.
This method is roughly equivalent to self.and_then(|x| x).
Note that this function consumes the receiving future and returns a wrapped version of it.
Examples
use futures::prelude::*; use futures::future; let nested_future = future::ok::<_, u32>(future::ok::<u32, u32>(1)); let future = nested_future.flatten(); assert_eq!(future.wait(), Ok(1));
Calling flatten on an errored Future, or if the inner Future is
errored, will result in an errored Future:
use futures::prelude::*; use futures::future; let nested_future = future::ok::<_, u32>(future::err::<u32, u32>(1)); let future = nested_future.flatten(); assert_eq!(future.wait(), Err(1));
fn flatten_stream(self) -> FlattenStream<Self> where
    Self::Item: Stream,
    <Self::Item as Stream>::Error == Self::Error, 
Self::Item: Stream,
<Self::Item as Stream>::Error == Self::Error,
Flatten the execution of this future when the successful result of this future is a stream.
This can be useful when stream initialization is deferred, and it is convenient to work with that stream as if stream was available at the call site.
Note that this function consumes this future and returns a wrapped version of it.
Examples
use futures::prelude::*; use futures::future; use futures::stream; let stream_items = vec![17, 18, 19]; let future_of_a_stream = future::ok::<_, bool>(stream::iter_ok(stream_items)); let stream = future_of_a_stream.flatten_stream(); let mut iter = stream.wait(); assert_eq!(Ok(17), iter.next().unwrap()); assert_eq!(Ok(18), iter.next().unwrap()); assert_eq!(Ok(19), iter.next().unwrap()); assert_eq!(None, iter.next());
fn fuse(self) -> Fuse<Self>
Fuse a future such that poll will never again be called once it has
completed.
Currently once a future has returned Ready or Err from
poll any further calls could exhibit bad behavior such as blocking
forever, panicking, never returning, etc. If it is known that poll
may be called too often then this method can be used to ensure that it
has defined semantics.
Once a future has been fused and it returns a completion from poll,
then it will forever return NotReady from poll again (never
resolve).  This, unlike the trait's poll method, is guaranteed.
This combinator will drop this future as soon as it's been completed to ensure resources are reclaimed as soon as possible.
Examples
use futures::prelude::*; use futures::future; let mut future = future::ok::<i32, u32>(2); assert_eq!(future.poll(), Ok(Async::Ready(2))); // Normally, a call such as this would panic: //future.poll(); // This, however, is guaranteed to not panic let mut future = future::ok::<i32, u32>(2).fuse(); assert_eq!(future.poll(), Ok(Async::Ready(2))); assert_eq!(future.poll(), Ok(Async::NotReady));
fn inspect<F>(self, f: F) -> Inspect<Self, F> where
    F: FnOnce(&Self::Item), 
F: FnOnce(&Self::Item),
Do something with the item of a future, passing it on.
When using futures, you'll often chain several of them together. While working on such code, you might want to check out what's happening at various parts in the pipeline. To do that, insert a call to inspect().
Examples
use futures::prelude::*; use futures::future; let future = future::ok::<u32, u32>(1); let new_future = future.inspect(|&x| println!("about to resolve: {}", x)); assert_eq!(new_future.wait(), Ok(1));
fn catch_unwind(self) -> CatchUnwind<Self> where
    Self: UnwindSafe, 
Self: UnwindSafe,
Catches unwinding panics while polling the future.
In general, panics within a future can propagate all the way out to the task level. This combinator makes it possible to halt unwinding within the future itself. It's most commonly used within task executors. It's not recommended to use this for error handling.
Note that this method requires the UnwindSafe bound from the standard
library. This isn't always applied automatically, and the standard
library provides an AssertUnwindSafe wrapper type to apply it
after-the fact. To assist using this method, the Future trait is also
implemented for AssertUnwindSafe<F> where F implements Future.
This method is only available when the use_std feature of this
library is activated, and it is activated by default.
Examples
use futures::prelude::*; use futures::future::{self, FutureResult}; let mut future = future::ok::<i32, u32>(2); assert!(future.catch_unwind().wait().is_ok()); let mut future = future::lazy(|| -> FutureResult<i32, u32> { panic!(); future::ok::<i32, u32>(2) }); assert!(future.catch_unwind().wait().is_err());
fn shared(self) -> Shared<Self>
Create a cloneable handle to this future where all handles will resolve to the same result.
The shared() method provides a method to convert any future into a cloneable future. It enables a future to be polled by multiple threads.
The returned Shared future resolves successfully with
SharedItem<Self::Item> or erroneously with SharedError<Self::Error>.
Both SharedItem and SharedError implements Deref to allow shared
access to the underlying result. Ownership of Self::Item and
Self::Error cannot currently be reclaimed.
This method is only available when the use_std feature of this
library is activated, and it is activated by default.
Examples
use futures::prelude::*; use futures::future; let future = future::ok::<_, bool>(6); let shared1 = future.shared(); let shared2 = shared1.clone(); assert_eq!(6, *shared1.wait().unwrap()); assert_eq!(6, *shared2.wait().unwrap());
use std::thread; use futures::prelude::*; use futures::future; let future = future::ok::<_, bool>(6); let shared1 = future.shared(); let shared2 = shared1.clone(); let join_handle = thread::spawn(move || { assert_eq!(6, *shared2.wait().unwrap()); }); assert_eq!(6, *shared1.wait().unwrap()); join_handle.join().unwrap();
Implementations on Foreign Types
impl<S> Future for Flush<S> where
    S: Sink, [src]
S: Sink,
type Item = S
type Error = <S as Sink>::SinkError
fn poll(&mut self) -> Result<Async<S>, <S as Sink>::SinkError>[src]
impl<T, U> Future for SendAll<T, U> where
    T: Sink,
    U: Stream<Item = <T as Sink>::SinkItem>,
    <T as Sink>::SinkError: From<<U as Stream>::Error>, [src]
T: Sink,
U: Stream<Item = <T as Sink>::SinkItem>,
<T as Sink>::SinkError: From<<U as Stream>::Error>,
type Item = (T, U)
type Error = <T as Sink>::SinkError
fn poll(&mut self) -> Result<Async<(T, U)>, <T as Sink>::SinkError>[src]
impl<T> Future for BiLockAcquire<T>[src]
type Item = BiLockAcquired<T>
type Error = ()
fn poll(&mut self) -> Result<Async<BiLockAcquired<T>>, ()>[src]
impl<F> Future for Execute<F> where
    F: Future, [src]
F: Future,
impl<T> Future for Receiver<T>[src]
impl<S> Future for Execute<S> where
    S: Stream, [src]
S: Stream,
impl<T> Future for Receiver<T>[src]
type Item = T
type Error = Canceled
fn poll(
    &mut self
) -> Result<Async<<Receiver<T> as Future>::Item>, <Receiver<T> as Future>::Error>[src]
&mut self
) -> Result<Async<<Receiver<T> as Future>::Item>, <Receiver<T> as Future>::Error>
impl<S> Future for Execute<S> where
    S: Stream, [src]
S: Stream,
impl<T, E> Future for SpawnHandle<T, E>[src]
impl<S> Future for Send<S> where
    S: Sink, [src]
S: Sink,
type Item = S
type Error = <S as Sink>::SinkError
fn poll(&mut self) -> Result<Async<S>, <S as Sink>::SinkError>[src]
impl<'a, F> Future for &'a mut F where
    F: Future + ?Sized, [src]
F: Future + ?Sized,
type Item = <F as Future>::Item
type Error = <F as Future>::Error
fn poll(
    &mut self
) -> Result<Async<<&'a mut F as Future>::Item>, <&'a mut F as Future>::Error>[src]
&mut self
) -> Result<Async<<&'a mut F as Future>::Item>, <&'a mut F as Future>::Error>
impl<F, T, E> Future for Option<F> where
    F: Future<Item = T, Error = E>, [src]
F: Future<Item = T, Error = E>,
impl<T, E> Future for SpawnHandle<T, E>[src]
impl<F> Future for Execute<F> where
    F: Future, [src]
F: Future,
impl<F> Future for Box<F> where
    F: Future + ?Sized, [src]
F: Future + ?Sized,
type Item = <F as Future>::Item
type Error = <F as Future>::Error
fn poll(
    &mut self
) -> Result<Async<<Box<F> as Future>::Item>, <Box<F> as Future>::Error>[src]
&mut self
) -> Result<Async<<Box<F> as Future>::Item>, <Box<F> as Future>::Error>
impl<F> Future for AssertUnwindSafe<F> where
    F: Future, [src]
F: Future,
type Item = <F as Future>::Item
type Error = <F as Future>::Error
fn poll(&mut self) -> Result<Async<<F as Future>::Item>, <F as Future>::Error>[src]
impl<R, T> Future for Read<R, T> where
    R: AsyncRead,
    T: AsMut<[u8]>, [src]
R: AsyncRead,
T: AsMut<[u8]>,
type Item = (R, T, usize)
type Error = Error
fn poll(&mut self) -> Result<Async<(R, T, usize)>, Error>[src]
impl<P> Future for ReadLinkFuture<P> where
    P: AsRef<Path>, [src]
P: AsRef<Path>,
type Item = PathBuf
type Error = Error
fn poll(
    &mut self
) -> Result<Async<<ReadLinkFuture<P> as Future>::Item>, <ReadLinkFuture<P> as Future>::Error>[src]
&mut self
) -> Result<Async<<ReadLinkFuture<P> as Future>::Item>, <ReadLinkFuture<P> as Future>::Error>
impl<P, Q> Future for RenameFuture<P, Q> where
    P: AsRef<Path>,
    Q: AsRef<Path>, [src]
P: AsRef<Path>,
Q: AsRef<Path>,
type Item = ()
type Error = Error
fn poll(
    &mut self
) -> Result<Async<<RenameFuture<P, Q> as Future>::Item>, <RenameFuture<P, Q> as Future>::Error>[src]
&mut self
) -> Result<Async<<RenameFuture<P, Q> as Future>::Item>, <RenameFuture<P, Q> as Future>::Error>
impl<P> Future for ReadDirFuture<P> where
    P: AsRef<Path> + Send + 'static, [src]
P: AsRef<Path> + Send + 'static,
type Item = ReadDir
type Error = Error
fn poll(&mut self) -> Result<Async<<ReadDirFuture<P> as Future>::Item>, Error>[src]
impl<P> Future for CreateDirAllFuture<P> where
    P: AsRef<Path>, [src]
P: AsRef<Path>,
type Item = ()
type Error = Error
fn poll(
    &mut self
) -> Result<Async<<CreateDirAllFuture<P> as Future>::Item>, <CreateDirAllFuture<P> as Future>::Error>[src]
&mut self
) -> Result<Async<<CreateDirAllFuture<P> as Future>::Item>, <CreateDirAllFuture<P> as Future>::Error>
impl<P> Future for CreateDirFuture<P> where
    P: AsRef<Path>, [src]
P: AsRef<Path>,
type Item = ()
type Error = Error
fn poll(
    &mut self
) -> Result<Async<<CreateDirFuture<P> as Future>::Item>, <CreateDirFuture<P> as Future>::Error>[src]
&mut self
) -> Result<Async<<CreateDirFuture<P> as Future>::Item>, <CreateDirFuture<P> as Future>::Error>
impl<P, Q> Future for HardLinkFuture<P, Q> where
    P: AsRef<Path>,
    Q: AsRef<Path>, [src]
P: AsRef<Path>,
Q: AsRef<Path>,
type Item = ()
type Error = Error
fn poll(
    &mut self
) -> Result<Async<<HardLinkFuture<P, Q> as Future>::Item>, <HardLinkFuture<P, Q> as Future>::Error>[src]
&mut self
) -> Result<Async<<HardLinkFuture<P, Q> as Future>::Item>, <HardLinkFuture<P, Q> as Future>::Error>
impl<P> Future for SetPermissionsFuture<P> where
    P: AsRef<Path>, [src]
P: AsRef<Path>,
type Item = ()
type Error = Error
fn poll(
    &mut self
) -> Result<Async<<SetPermissionsFuture<P> as Future>::Item>, <SetPermissionsFuture<P> as Future>::Error>[src]
&mut self
) -> Result<Async<<SetPermissionsFuture<P> as Future>::Item>, <SetPermissionsFuture<P> as Future>::Error>
impl<P> Future for RemoveDirFuture<P> where
    P: AsRef<Path>, [src]
P: AsRef<Path>,
type Item = ()
type Error = Error
fn poll(
    &mut self
) -> Result<Async<<RemoveDirFuture<P> as Future>::Item>, <RemoveDirFuture<P> as Future>::Error>[src]
&mut self
) -> Result<Async<<RemoveDirFuture<P> as Future>::Item>, <RemoveDirFuture<P> as Future>::Error>
impl<P> Future for SymlinkMetadataFuture<P> where
    P: AsRef<Path> + Send + 'static, [src]
P: AsRef<Path> + Send + 'static,
type Item = Metadata
type Error = Error
fn poll(
    &mut self
) -> Result<Async<<SymlinkMetadataFuture<P> as Future>::Item>, <SymlinkMetadataFuture<P> as Future>::Error>[src]
&mut self
) -> Result<Async<<SymlinkMetadataFuture<P> as Future>::Item>, <SymlinkMetadataFuture<P> as Future>::Error>
impl<P> Future for MetadataFuture<P> where
    P: AsRef<Path> + Send + 'static, [src]
P: AsRef<Path> + Send + 'static,
type Item = Metadata
type Error = Error
fn poll(
    &mut self
) -> Result<Async<<MetadataFuture<P> as Future>::Item>, <MetadataFuture<P> as Future>::Error>[src]
&mut self
) -> Result<Async<<MetadataFuture<P> as Future>::Item>, <MetadataFuture<P> as Future>::Error>
impl<P> Future for RemoveFileFuture<P> where
    P: AsRef<Path>, [src]
P: AsRef<Path>,
type Item = ()
type Error = Error
fn poll(
    &mut self
) -> Result<Async<<RemoveFileFuture<P> as Future>::Item>, <RemoveFileFuture<P> as Future>::Error>[src]
&mut self
) -> Result<Async<<RemoveFileFuture<P> as Future>::Item>, <RemoveFileFuture<P> as Future>::Error>
impl<T, E> Future for SpawnHandle<T, E>[src]
impl Future for Shutdown[src]
impl Future for Shutdown[src]
Loading content...
            Implementors
impl Future for CloneFuture[src]
type Item = (File, File)
type Error = (File, Error)
fn poll(
    &mut self
) -> Result<Async<<CloneFuture as Future>::Item>, <CloneFuture as Future>::Error>[src]
&mut self
) -> Result<Async<<CloneFuture as Future>::Item>, <CloneFuture as Future>::Error>
impl Future for tokio::fs::file::MetadataFuture[src]
type Item = (File, Metadata)
type Error = Error
fn poll(
    &mut self
) -> Result<Async<<MetadataFuture as Future>::Item>, <MetadataFuture as Future>::Error>[src]
&mut self
) -> Result<Async<<MetadataFuture as Future>::Item>, <MetadataFuture as Future>::Error>
impl Future for SeekFuture[src]
type Item = (File, u64)
type Error = Error
fn poll(
    &mut self
) -> Result<Async<<SeekFuture as Future>::Item>, <SeekFuture as Future>::Error>[src]
&mut self
) -> Result<Async<<SeekFuture as Future>::Item>, <SeekFuture as Future>::Error>
impl Future for tokio::net::tcp::ConnectFuture[src]
impl Future for tokio::net::unix::ConnectFuture[src]
impl Future for tokio::runtime::Shutdown[src]
impl Future for Delay[src]
type Item = ()
type Error = Error
fn poll(
    &mut self
) -> Result<Async<<Delay as Future>::Item>, <Delay as Future>::Error>[src]
&mut self
) -> Result<Async<<Delay as Future>::Item>, <Delay as Future>::Error>
impl<A> Future for tokio::io::Flush<A> where
    A: AsyncWrite, [src]
A: AsyncWrite,
impl<A> Future for ReadToEnd<A> where
    A: AsyncRead, [src]
A: AsyncRead,
type Item = (A, Vec<u8>)
type Error = Error
fn poll(&mut self) -> Result<Async<(A, Vec<u8>)>, Error>[src]
impl<A> Future for ReadUntil<A> where
    A: AsyncRead + BufRead, [src]
A: AsyncRead + BufRead,
type Item = (A, Vec<u8>)
type Error = Error
fn poll(&mut self) -> Result<Async<(A, Vec<u8>)>, Error>[src]
impl<A> Future for tokio::io::Shutdown<A> where
    A: AsyncWrite, [src]
A: AsyncWrite,
impl<A> Future for Flatten<A> where
    A: Future,
    <A as Future>::Item: IntoFuture,
    <<A as Future>::Item as IntoFuture>::Error: From<<A as Future>::Error>, [src]
A: Future,
<A as Future>::Item: IntoFuture,
<<A as Future>::Item as IntoFuture>::Error: From<<A as Future>::Error>,
type Item = <<A as Future>::Item as IntoFuture>::Item
type Error = <<A as Future>::Item as IntoFuture>::Error
fn poll(
    &mut self
) -> Result<Async<<Flatten<A> as Future>::Item>, <Flatten<A> as Future>::Error>[src]
&mut self
) -> Result<Async<<Flatten<A> as Future>::Item>, <Flatten<A> as Future>::Error>
impl<A> Future for Fuse<A> where
    A: Future, [src]
A: Future,
type Item = <A as Future>::Item
type Error = <A as Future>::Error
fn poll(&mut self) -> Result<Async<<A as Future>::Item>, <A as Future>::Error>[src]
impl<A> Future for SelectAll<A> where
    A: Future, [src]
A: Future,
type Item = (<A as Future>::Item, usize, Vec<A>)
type Error = (<A as Future>::Error, usize, Vec<A>)
fn poll(
    &mut self
) -> Result<Async<<SelectAll<A> as Future>::Item>, <SelectAll<A> as Future>::Error>[src]
&mut self
) -> Result<Async<<SelectAll<A> as Future>::Item>, <SelectAll<A> as Future>::Error>
impl<A> Future for SelectOk<A> where
    A: Future, [src]
A: Future,
type Item = (<A as Future>::Item, Vec<A>)
type Error = <A as Future>::Error
fn poll(
    &mut self
) -> Result<Async<<SelectOk<A> as Future>::Item>, <SelectOk<A> as Future>::Error>[src]
&mut self
) -> Result<Async<<SelectOk<A> as Future>::Item>, <SelectOk<A> as Future>::Error>
impl<A, B> Future for Either<A, B> where
    A: Future,
    B: Future<Item = <A as Future>::Item, Error = <A as Future>::Error>, [src]
A: Future,
B: Future<Item = <A as Future>::Item, Error = <A as Future>::Error>,
type Item = <A as Future>::Item
type Error = <A as Future>::Error
fn poll(&mut self) -> Result<Async<<A as Future>::Item>, <A as Future>::Error>[src]
impl<A, B> Future for Join<A, B> where
    A: Future,
    B: Future<Error = <A as Future>::Error>, [src]
A: Future,
B: Future<Error = <A as Future>::Error>,
type Item = (<A as Future>::Item, <B as Future>::Item)
type Error = <A as Future>::Error
fn poll(
    &mut self
) -> Result<Async<<Join<A, B> as Future>::Item>, <Join<A, B> as Future>::Error>[src]
&mut self
) -> Result<Async<<Join<A, B> as Future>::Item>, <Join<A, B> as Future>::Error>
impl<A, B> Future for Select<A, B> where
    A: Future,
    B: Future<Item = <A as Future>::Item, Error = <A as Future>::Error>, [src]
A: Future,
B: Future<Item = <A as Future>::Item, Error = <A as Future>::Error>,
type Item = (<A as Future>::Item, SelectNext<A, B>)
type Error = (<A as Future>::Error, SelectNext<A, B>)
fn poll(
    &mut self
) -> Result<Async<<Select<A, B> as Future>::Item>, <Select<A, B> as Future>::Error>[src]
&mut self
) -> Result<Async<<Select<A, B> as Future>::Item>, <Select<A, B> as Future>::Error>
impl<A, B> Future for Select2<A, B> where
    A: Future,
    B: Future, [src]
A: Future,
B: Future,
type Item = Either<(<A as Future>::Item, B), (<B as Future>::Item, A)>
type Error = Either<(<A as Future>::Error, B), (<B as Future>::Error, A)>
fn poll(
    &mut self
) -> Result<Async<<Select2<A, B> as Future>::Item>, <Select2<A, B> as Future>::Error>[src]
&mut self
) -> Result<Async<<Select2<A, B> as Future>::Item>, <Select2<A, B> as Future>::Error>
impl<A, B> Future for SelectNext<A, B> where
    A: Future,
    B: Future<Item = <A as Future>::Item, Error = <A as Future>::Error>, [src]
A: Future,
B: Future<Item = <A as Future>::Item, Error = <A as Future>::Error>,
type Item = <A as Future>::Item
type Error = <A as Future>::Error
fn poll(
    &mut self
) -> Result<Async<<SelectNext<A, B> as Future>::Item>, <SelectNext<A, B> as Future>::Error>[src]
&mut self
) -> Result<Async<<SelectNext<A, B> as Future>::Item>, <SelectNext<A, B> as Future>::Error>
impl<A, B, C> Future for Join3<A, B, C> where
    A: Future,
    B: Future<Error = <A as Future>::Error>,
    C: Future<Error = <A as Future>::Error>, [src]
A: Future,
B: Future<Error = <A as Future>::Error>,
C: Future<Error = <A as Future>::Error>,
type Item = (<A as Future>::Item, <B as Future>::Item, <C as Future>::Item)
type Error = <A as Future>::Error
fn poll(
    &mut self
) -> Result<Async<<Join3<A, B, C> as Future>::Item>, <Join3<A, B, C> as Future>::Error>[src]
&mut self
) -> Result<Async<<Join3<A, B, C> as Future>::Item>, <Join3<A, B, C> as Future>::Error>
impl<A, B, C, D> Future for Join4<A, B, C, D> where
    A: Future,
    B: Future<Error = <A as Future>::Error>,
    C: Future<Error = <A as Future>::Error>,
    D: Future<Error = <A as Future>::Error>, [src]
A: Future,
B: Future<Error = <A as Future>::Error>,
C: Future<Error = <A as Future>::Error>,
D: Future<Error = <A as Future>::Error>,
type Item = (<A as Future>::Item, <B as Future>::Item, <C as Future>::Item, <D as Future>::Item)
type Error = <A as Future>::Error
fn poll(
    &mut self
) -> Result<Async<<Join4<A, B, C, D> as Future>::Item>, <Join4<A, B, C, D> as Future>::Error>[src]
&mut self
) -> Result<Async<<Join4<A, B, C, D> as Future>::Item>, <Join4<A, B, C, D> as Future>::Error>
impl<A, B, C, D, E> Future for Join5<A, B, C, D, E> where
    A: Future,
    B: Future<Error = <A as Future>::Error>,
    C: Future<Error = <A as Future>::Error>,
    D: Future<Error = <A as Future>::Error>,
    E: Future<Error = <A as Future>::Error>, [src]
A: Future,
B: Future<Error = <A as Future>::Error>,
C: Future<Error = <A as Future>::Error>,
D: Future<Error = <A as Future>::Error>,
E: Future<Error = <A as Future>::Error>,
type Item = (<A as Future>::Item, <B as Future>::Item, <C as Future>::Item, <D as Future>::Item, <E as Future>::Item)
type Error = <A as Future>::Error
fn poll(
    &mut self
) -> Result<Async<<Join5<A, B, C, D, E> as Future>::Item>, <Join5<A, B, C, D, E> as Future>::Error>[src]
&mut self
) -> Result<Async<<Join5<A, B, C, D, E> as Future>::Item>, <Join5<A, B, C, D, E> as Future>::Error>
impl<A, B, F> Future for AndThen<A, B, F> where
    A: Future,
    B: IntoFuture<Error = <A as Future>::Error>,
    F: FnOnce(<A as Future>::Item) -> B, [src]
A: Future,
B: IntoFuture<Error = <A as Future>::Error>,
F: FnOnce(<A as Future>::Item) -> B,
type Item = <B as IntoFuture>::Item
type Error = <B as IntoFuture>::Error
fn poll(
    &mut self
) -> Result<Async<<B as IntoFuture>::Item>, <B as IntoFuture>::Error>[src]
&mut self
) -> Result<Async<<B as IntoFuture>::Item>, <B as IntoFuture>::Error>
impl<A, B, F> Future for OrElse<A, B, F> where
    A: Future,
    B: IntoFuture<Item = <A as Future>::Item>,
    F: FnOnce(<A as Future>::Error) -> B, [src]
A: Future,
B: IntoFuture<Item = <A as Future>::Item>,
F: FnOnce(<A as Future>::Error) -> B,
type Item = <B as IntoFuture>::Item
type Error = <B as IntoFuture>::Error
fn poll(
    &mut self
) -> Result<Async<<B as IntoFuture>::Item>, <B as IntoFuture>::Error>[src]
&mut self
) -> Result<Async<<B as IntoFuture>::Item>, <B as IntoFuture>::Error>
impl<A, B, F> Future for Then<A, B, F> where
    A: Future,
    B: IntoFuture,
    F: FnOnce(Result<<A as Future>::Item, <A as Future>::Error>) -> B, [src]
A: Future,
B: IntoFuture,
F: FnOnce(Result<<A as Future>::Item, <A as Future>::Error>) -> B,
type Item = <B as IntoFuture>::Item
type Error = <B as IntoFuture>::Error
fn poll(
    &mut self
) -> Result<Async<<B as IntoFuture>::Item>, <B as IntoFuture>::Error>[src]
&mut self
) -> Result<Async<<B as IntoFuture>::Item>, <B as IntoFuture>::Error>
impl<A, E> Future for FromErr<A, E> where
    A: Future,
    E: From<<A as Future>::Error>, [src]
A: Future,
E: From<<A as Future>::Error>,
type Item = <A as Future>::Item
type Error = E
fn poll(&mut self) -> Result<Async<<A as Future>::Item>, E>[src]
impl<A, F> Future for Inspect<A, F> where
    A: Future,
    F: FnOnce(&<A as Future>::Item), [src]
A: Future,
F: FnOnce(&<A as Future>::Item),
type Item = <A as Future>::Item
type Error = <A as Future>::Error
fn poll(&mut self) -> Result<Async<<A as Future>::Item>, <A as Future>::Error>[src]
impl<A, T> Future for ReadExact<A, T> where
    A: AsyncRead,
    T: AsMut<[u8]>, [src]
A: AsyncRead,
T: AsMut<[u8]>,
impl<A, T> Future for WriteAll<A, T> where
    A: AsyncWrite,
    T: AsRef<[u8]>, [src]
A: AsyncWrite,
T: AsRef<[u8]>,
impl<F> Future for CatchUnwind<F> where
    F: Future + UnwindSafe, [src]
F: Future + UnwindSafe,
type Item = Result<<F as Future>::Item, <F as Future>::Error>
type Error = Box<dyn Any + 'static + Send>
fn poll(
    &mut self
) -> Result<Async<<CatchUnwind<F> as Future>::Item>, <CatchUnwind<F> as Future>::Error>[src]
&mut self
) -> Result<Async<<CatchUnwind<F> as Future>::Item>, <CatchUnwind<F> as Future>::Error>
impl<F> Future for Shared<F> where
    F: Future, [src]
F: Future,
type Item = SharedItem<<F as Future>::Item>
type Error = SharedError<<F as Future>::Error>
fn poll(
    &mut self
) -> Result<Async<<Shared<F> as Future>::Item>, <Shared<F> as Future>::Error>[src]
&mut self
) -> Result<Async<<Shared<F> as Future>::Item>, <Shared<F> as Future>::Error>
impl<F, R> Future for Lazy<F, R> where
    F: FnOnce() -> R,
    R: IntoFuture, [src]
F: FnOnce() -> R,
R: IntoFuture,
type Item = <R as IntoFuture>::Item
type Error = <R as IntoFuture>::Error
fn poll(
    &mut self
) -> Result<Async<<R as IntoFuture>::Item>, <R as IntoFuture>::Error>[src]
&mut self
) -> Result<Async<<R as IntoFuture>::Item>, <R as IntoFuture>::Error>
impl<I> Future for JoinAll<I> where
    I: IntoIterator,
    <I as IntoIterator>::Item: IntoFuture, [src]
I: IntoIterator,
<I as IntoIterator>::Item: IntoFuture,
type Item = Vec<<<I as IntoIterator>::Item as IntoFuture>::Item>
type Error = <<I as IntoIterator>::Item as IntoFuture>::Error
fn poll(
    &mut self
) -> Result<Async<<JoinAll<I> as Future>::Item>, <JoinAll<I> as Future>::Error>[src]
&mut self
) -> Result<Async<<JoinAll<I> as Future>::Item>, <JoinAll<I> as Future>::Error>
impl<P> Future for CreateFuture<P> where
    P: AsRef<Path> + Send + 'static, [src]
P: AsRef<Path> + Send + 'static,
type Item = File
type Error = Error
fn poll(
    &mut self
) -> Result<Async<<CreateFuture<P> as Future>::Item>, <CreateFuture<P> as Future>::Error>[src]
&mut self
) -> Result<Async<<CreateFuture<P> as Future>::Item>, <CreateFuture<P> as Future>::Error>
impl<P> Future for OpenFuture<P> where
    P: AsRef<Path> + Send + 'static, [src]
P: AsRef<Path> + Send + 'static,
type Item = File
type Error = Error
fn poll(
    &mut self
) -> Result<Async<<OpenFuture<P> as Future>::Item>, <OpenFuture<P> as Future>::Error>[src]
&mut self
) -> Result<Async<<OpenFuture<P> as Future>::Item>, <OpenFuture<P> as Future>::Error>
impl<P> Future for ReadFile<P> where
    P: 'static + AsRef<Path> + Send, [src]
P: 'static + AsRef<Path> + Send,
type Item = Vec<u8>
type Error = Error
fn poll(
    &mut self
) -> Result<Async<<ReadFile<P> as Future>::Item>, <ReadFile<P> as Future>::Error>[src]
&mut self
) -> Result<Async<<ReadFile<P> as Future>::Item>, <ReadFile<P> as Future>::Error>
impl<P, C> Future for WriteFile<P, C> where
    C: AsRef<[u8]> + Debug,
    P: 'static + AsRef<Path> + Send, [src]
C: AsRef<[u8]> + Debug,
P: 'static + AsRef<Path> + Send,
type Item = C
type Error = Error
fn poll(
    &mut self
) -> Result<Async<<WriteFile<P, C> as Future>::Item>, <WriteFile<P, C> as Future>::Error>[src]
&mut self
) -> Result<Async<<WriteFile<P, C> as Future>::Item>, <WriteFile<P, C> as Future>::Error>
impl<P, Q> Future for SymlinkFuture<P, Q> where
    P: AsRef<Path>,
    Q: AsRef<Path>, [src]
P: AsRef<Path>,
Q: AsRef<Path>,
type Item = ()
type Error = Error
fn poll(
    &mut self
) -> Result<Async<<SymlinkFuture<P, Q> as Future>::Item>, <SymlinkFuture<P, Q> as Future>::Error>[src]
&mut self
) -> Result<Async<<SymlinkFuture<P, Q> as Future>::Item>, <SymlinkFuture<P, Q> as Future>::Error>
impl<R, W> Future for Copy<R, W> where
    R: AsyncRead,
    W: AsyncWrite, [src]
R: AsyncRead,
W: AsyncWrite,
type Item = (u64, R, W)
type Error = Error
fn poll(&mut self) -> Result<Async<(u64, R, W)>, Error>[src]
impl<S> Future for Collect<S> where
    S: Stream, [src]
S: Stream,
type Item = Vec<<S as Stream>::Item>
type Error = <S as Stream>::Error
fn poll(
    &mut self
) -> Result<Async<Vec<<S as Stream>::Item>>, <S as Stream>::Error>[src]
&mut self
) -> Result<Async<Vec<<S as Stream>::Item>>, <S as Stream>::Error>
impl<S> Future for Concat<S> where
    S: Stream,
    <S as Stream>::Item: Extend<<<S as Stream>::Item as IntoIterator>::Item>,
    <S as Stream>::Item: IntoIterator, [src]
S: Stream,
<S as Stream>::Item: Extend<<<S as Stream>::Item as IntoIterator>::Item>,
<S as Stream>::Item: IntoIterator,
type Item = <S as Stream>::Item
type Error = <S as Stream>::Error
fn poll(
    &mut self
) -> Result<Async<<Concat<S> as Future>::Item>, <Concat<S> as Future>::Error>[src]
&mut self
) -> Result<Async<<Concat<S> as Future>::Item>, <Concat<S> as Future>::Error>
impl<S> Future for Concat2<S> where
    S: Stream,
    <S as Stream>::Item: Extend<<<S as Stream>::Item as IntoIterator>::Item>,
    <S as Stream>::Item: IntoIterator,
    <S as Stream>::Item: Default, [src]
S: Stream,
<S as Stream>::Item: Extend<<<S as Stream>::Item as IntoIterator>::Item>,
<S as Stream>::Item: IntoIterator,
<S as Stream>::Item: Default,
type Item = <S as Stream>::Item
type Error = <S as Stream>::Error
fn poll(
    &mut self
) -> Result<Async<<Concat2<S> as Future>::Item>, <Concat2<S> as Future>::Error>[src]
&mut self
) -> Result<Async<<Concat2<S> as Future>::Item>, <Concat2<S> as Future>::Error>
impl<S> Future for StreamFuture<S> where
    S: Stream, [src]
S: Stream,
type Item = (Option<<S as Stream>::Item>, S)
type Error = (<S as Stream>::Error, S)
fn poll(
    &mut self
) -> Result<Async<<StreamFuture<S> as Future>::Item>, <StreamFuture<S> as Future>::Error>[src]
&mut self
) -> Result<Async<<StreamFuture<S> as Future>::Item>, <StreamFuture<S> as Future>::Error>
impl<S, F, Fut, T> Future for Fold<S, F, Fut, T> where
    F: FnMut(T, <S as Stream>::Item) -> Fut,
    Fut: IntoFuture<Item = T>,
    S: Stream,
    <S as Stream>::Error: From<<Fut as IntoFuture>::Error>, [src]
F: FnMut(T, <S as Stream>::Item) -> Fut,
Fut: IntoFuture<Item = T>,
S: Stream,
<S as Stream>::Error: From<<Fut as IntoFuture>::Error>,
type Item = T
type Error = <S as Stream>::Error
fn poll(&mut self) -> Result<Async<T>, <S as Stream>::Error>[src]
impl<S, F, U> Future for ForEach<S, F, U> where
    F: FnMut(<S as Stream>::Item) -> U,
    S: Stream,
    U: IntoFuture<Item = (), Error = <S as Stream>::Error>, [src]
F: FnMut(<S as Stream>::Item) -> U,
S: Stream,
U: IntoFuture<Item = (), Error = <S as Stream>::Error>,
type Item = ()
type Error = <S as Stream>::Error
fn poll(&mut self) -> Result<Async<()>, <S as Stream>::Error>[src]
impl<S, T, A, F> Future for LoopFn<A, F> where
    A: IntoFuture<Item = Loop<T, S>>,
    F: FnMut(S) -> A, [src]
A: IntoFuture<Item = Loop<T, S>>,
F: FnMut(S) -> A,
type Item = T
type Error = <A as IntoFuture>::Error
fn poll(
    &mut self
) -> Result<Async<<LoopFn<A, F> as Future>::Item>, <LoopFn<A, F> as Future>::Error>[src]
&mut self
) -> Result<Async<<LoopFn<A, F> as Future>::Item>, <LoopFn<A, F> as Future>::Error>
impl<T> Future for tokio::net::udp::RecvDgram<T> where
    T: AsMut<[u8]>, [src]
T: AsMut<[u8]>,
type Item = (UdpSocket, T, usize, SocketAddr)
type Error = Error
fn poll(&mut self) -> Result<Async<<RecvDgram<T> as Future>::Item>, Error>[src]
impl<T> Future for tokio::net::udp::SendDgram<T> where
    T: AsRef<[u8]>, [src]
T: AsRef<[u8]>,
type Item = (UdpSocket, T)
type Error = Error
fn poll(&mut self) -> Result<Async<(UdpSocket, T)>, Error>[src]
impl<T> Future for tokio::net::unix::RecvDgram<T> where
    T: AsMut<[u8]>, [src]
T: AsMut<[u8]>,
type Item = (UnixDatagram, T, usize, String)
RecvDgram yields a tuple of the underlying socket, the receive buffer, how many bytes were received, and the address (path) of the peer sending the datagram. If the buffer is too small, the datagram is truncated.
type Error = Error
This future yields io::Error if an error occurred.
fn poll(
    &mut self
) -> Result<Async<<RecvDgram<T> as Future>::Item>, <RecvDgram<T> as Future>::Error>[src]
&mut self
) -> Result<Async<<RecvDgram<T> as Future>::Item>, <RecvDgram<T> as Future>::Error>
impl<T> Future for tokio::sync::oneshot::Receiver<T>[src]
impl<T> Future for Timeout<T> where
    T: Future, [src]
T: Future,
type Item = <T as Future>::Item
type Error = Error<<T as Future>::Error>
fn poll(
    &mut self
) -> Result<Async<<Timeout<T> as Future>::Item>, <Timeout<T> as Future>::Error>[src]
&mut self
) -> Result<Async<<Timeout<T> as Future>::Item>, <Timeout<T> as Future>::Error>
impl<T, E> Future for Empty<T, E>[src]
impl<T, E> Future for FutureResult<T, E>[src]
impl<T, E> Future for FutureSender<T, E>[src]
type Item = Sender<T, E>
type Error = SendError<T, E>
fn poll(
    &mut self
) -> Result<Async<<FutureSender<T, E> as Future>::Item>, <FutureSender<T, E> as Future>::Error>[src]
&mut self
) -> Result<Async<<FutureSender<T, E> as Future>::Item>, <FutureSender<T, E> as Future>::Error>
impl<T, E, F> Future for PollFn<F> where
    F: FnMut() -> Result<Async<T>, E>, [src]
F: FnMut() -> Result<Async<T>, E>,
impl<T, P> Future for tokio::net::unix::SendDgram<T, P> where
    P: AsRef<Path>,
    T: AsRef<[u8]>, [src]
P: AsRef<Path>,
T: AsRef<[u8]>,
type Item = (UnixDatagram, T)
Returns the underlying socket and the buffer that was sent.
type Error = Error
The error that is returned when sending failed.
fn poll(
    &mut self
) -> Result<Async<<SendDgram<T, P> as Future>::Item>, <SendDgram<T, P> as Future>::Error>[src]
&mut self
) -> Result<Async<<SendDgram<T, P> as Future>::Item>, <SendDgram<T, P> as Future>::Error>
impl<T, U> Future for Forward<T, U> where
    T: Stream,
    U: Sink<SinkItem = <T as Stream>::Item>,
    <T as Stream>::Error: From<<U as Sink>::SinkError>, [src]
T: Stream,
U: Sink<SinkItem = <T as Stream>::Item>,
<T as Stream>::Error: From<<U as Sink>::SinkError>,
type Item = (T, U)
type Error = <T as Stream>::Error
fn poll(&mut self) -> Result<Async<(T, U)>, <T as Stream>::Error>[src]
impl<U, A, F> Future for Map<A, F> where
    A: Future,
    F: FnOnce(<A as Future>::Item) -> U, [src]
A: Future,
F: FnOnce(<A as Future>::Item) -> U,
type Item = U
type Error = <A as Future>::Error
fn poll(&mut self) -> Result<Async<U>, <A as Future>::Error>[src]
impl<U, A, F> Future for MapErr<A, F> where
    A: Future,
    F: FnOnce(<A as Future>::Error) -> U, [src]
A: Future,
F: FnOnce(<A as Future>::Error) -> U,