futures/lib.rs
1//! Abstractions for asynchronous programming.
2//!
3//! This crate provides a number of core abstractions for writing asynchronous code:
4//!
5//! - [Futures](::Future) (sometimes called promises), which represent a single
6//! asychronous computation that may result in a final value or an error.
7//!
8//! - [Streams](::Stream), which represent a series of values or errors produced asynchronously.
9//!
10//! - [Sinks](::Sink), which support asynchronous writing of data.
11//!
12//! - [Executors](::executor), which are responsible for running asynchronous tasks.
13//!
14//! The crate also contains abstractions for [asynchronous I/O](::io) and
15//! [cross-task communication](::channel).
16//!
17//! Underlying all of this is the *task system*, which is a form of lightweight
18//! threading. Large asynchronous computations are built up using futures,
19//! streams and sinks, and then spawned as independent tasks that are run to
20//! completion, but *do not block* the thread running them.
21
22#![no_std]
23#![doc(html_root_url = "https://docs.rs/futures/0.2.2")]
24
25#![cfg_attr(feature = "nightly", feature(cfg_target_has_atomic))]
26#![cfg_attr(feature = "nightly", feature(use_extern_macros))]
27
28extern crate futures_async_runtime;
29extern crate futures_core;
30extern crate futures_channel;
31extern crate futures_executor;
32extern crate futures_io;
33extern crate futures_sink;
34extern crate futures_stable;
35extern crate futures_util;
36
37#[cfg(feature = "nightly")] extern crate futures_macro_async;
38#[cfg(feature = "nightly")] extern crate futures_macro_await;
39
40pub use futures_core::future::{Future, IntoFuture};
41pub use futures_util::future::FutureExt;
42pub use futures_core::stream::Stream;
43pub use futures_util::stream::StreamExt;
44pub use futures_sink::Sink;
45pub use futures_util::sink::SinkExt;
46
47// Macros redefined here because macro re-exports are unstable.
48
49/// A macro for extracting the successful type of a `Poll<T, E>`.
50///
51/// This macro bakes in propagation of both errors and `Pending` signals by
52/// returning early.
53#[macro_export]
54macro_rules! try_ready {
55 ($e:expr) => (match $e {
56 Ok($crate::prelude::Async::Ready(t)) => t,
57 Ok($crate::prelude::Async::Pending) => return Ok($crate::prelude::Async::Pending),
58 Err(e) => return Err(From::from(e)),
59 })
60}
61
62/// A macro to create a `static` of type `LocalKey`.
63///
64/// This macro is intentionally similar to the `thread_local!`, and creates a
65/// `static` which has a `get_mut` method to access the data on a task.
66///
67/// The data associated with each task local is per-task, so different tasks
68/// will contain different values.
69#[macro_export]
70macro_rules! task_local {
71 (static $NAME:ident: $t:ty = $e:expr) => (
72 static $NAME: $crate::task::LocalKey<$t> = {
73 fn __init() -> $t { $e }
74 fn __key() -> ::std::any::TypeId {
75 struct __A;
76 ::std::any::TypeId::of::<__A>()
77 }
78 $crate::task::LocalKey {
79 __init: __init,
80 __key: __key,
81 }
82 };
83 )
84}
85
86pub use futures_core::{Async, Poll, Never};
87
88#[cfg(feature = "std")]
89pub mod channel {
90 //! Cross-task communication.
91 //!
92 //! Like threads, concurrent tasks sometimes need to communicate with each
93 //! other. This module contains two basic abstractions for doing so:
94 //!
95 //! - [oneshot](::channel::oneshot), a way of sending a single value from
96 //! one task to another.
97 //!
98 //! - [mpsc](::channel::mpsc), a multi-producer, single-consumer channel for
99 //! sending values between tasks, analogous to the similarly-named structure
100 //! in the standard library.
101
102 pub use futures_channel::{oneshot, mpsc};
103}
104
105#[cfg(feature = "std")]
106pub mod executor {
107 //! Task execution.
108 //!
109 //! All asynchronous computation occurs within an executor, which is
110 //! capable of spawning futures as tasks. This module provides several
111 //! built-in executors, as well as tools for building your own.
112 //!
113 //! # Using a thread pool (M:N task scheduling)
114 //!
115 //! Most of the time tasks should be executed on a [thread
116 //! pool](::executor::ThreadPool). A small set of worker threads can handle
117 //! a very large set of spawned tasks (which are much lighter weight than
118 //! threads).
119 //!
120 //! The simplest way to use a thread pool is to
121 //! [`run`](::executor::ThreadPool::run) an initial task on it, which can
122 //! then spawn further tasks back onto the pool to complete its work:
123 //!
124 //! ```
125 //! use futures::executor::ThreadPool;
126 //! # use futures::future::{Future, lazy};
127 //! # let my_app: Box<Future<Item = (), Error = ()>> = Box::new(lazy(|_| Ok(())));
128 //!
129 //! // assuming `my_app: Future`
130 //! ThreadPool::new().expect("Failed to create threadpool").run(my_app);
131 //! ```
132 //!
133 //! The call to [`run`](::executor::ThreadPool::run) will block the current
134 //! thread until the future defined by `my_app` completes, and will return
135 //! the result of that future.
136 //!
137 //! # Spawning additional tasks
138 //!
139 //! There are two ways to spawn a task:
140 //!
141 //! - Spawn onto a "default" executor by calling the top-level
142 //! [`spawn`](::executor::spawn) function or [pulling the executor from the
143 //! task context](::task::Context::executor).
144 //!
145 //! - Spawn onto a specific executor by calling its
146 //! [`spawn`](::executor::Executor::spawn) method directly.
147 //!
148 //! Every task always has an associated default executor, which is usually
149 //! the executor on which the task is running.
150 //!
151 //! # Single-threaded execution
152 //!
153 //! In addition to thread pools, it's possible to run a task (and the tasks
154 //! it spawns) entirely within a single thread via the
155 //! [`LocalPool`](::executor::LocalPool) executor. Aside from cutting down
156 //! on synchronization costs, this executor also makes it possible to
157 //! execute non-`Send` tasks, via
158 //! [`spawn_local`](::executor::LocalExecutor::spawn_local). The `LocalPool`
159 //! is best suited for running I/O-bound tasks that do relatively little
160 //! work between I/O operations.
161 //!
162 //! There is also a convenience function,
163 //! [`block_on`](::executor::block_on), for simply running a future to
164 //! completion on the current thread, while routing any spawned tasks
165 //! to a global thread pool.
166 // TODO: add docs (or link to apr) for implementing an executor
167
168 pub use futures_executor::{
169 BlockingStream,
170 Enter, EnterError,
171 LocalExecutor, LocalPool,
172 Spawn, SpawnWithHandle,
173 ThreadPool, ThreadPoolBuilder, JoinHandle,
174 block_on, block_on_stream, enter, spawn, spawn_with_handle
175 };
176 pub use futures_core::executor::{SpawnError, Executor};
177}
178
179pub mod future {
180 //! Asynchronous values.
181 //!
182 //! This module contains:
183 //!
184 //! - The [`Future` trait](::Future).
185 //!
186 //! - The [`FutureExt`](::future::FutureExt) trait, which provides adapters
187 //! for chaining and composing futures.
188 //!
189 //! - Top-level future combinators like [`lazy`](::future::lazy) which
190 //! creates a future from a closure that defines its return value, and
191 //! [`result`](::future::result), which constructs a future with an
192 //! immediate defined value.
193
194 pub use futures_core::future::{
195 FutureOption, FutureResult, Future, IntoFuture, err, ok, result
196 };
197 pub use futures_util::future::{
198 AndThen, Empty, Flatten, FlattenStream, ErrInto, Fuse,
199 Inspect, IntoStream, Join, Join3, Join4, Join5, Lazy, LoopFn,
200 Map, MapErr, OrElse, PollFn, Select, Then, Either, Loop, FutureExt, empty,
201 lazy, loop_fn, poll_fn
202 };
203
204 #[cfg(feature = "std")]
205 pub use futures_util::future::{
206 CatchUnwind, JoinAll, SelectAll, SelectOk, Shared, SharedError, SharedItem,
207 join_all, select_all, select_ok
208 };
209}
210
211#[cfg(feature = "std")]
212pub mod io {
213 //! Asynchronous I/O.
214 //!
215 //! This module is the asynchronous version of `std::io`. It defines two
216 //! traits, [`AsyncRead`](::io::AsyncRead) and
217 //! [`AsyncWrite`](::io::AsyncWrite), which mirror the `Read` and `Write`
218 //! traits of the standard library. However, these traits integrate with the
219 //! asynchronous task system, so that if an I/O object isn't ready for
220 //! reading (or writing), the thread is not blocked, and instead the current
221 //! task is queued to be woken when I/O is ready.
222 //!
223 //! In addition, the [`AsyncReadExt`](::io::AsyncReadExt) and
224 //! [`AsyncWriteExt`](::io::AsyncWriteExt) extension traits offer a variety
225 //! of useful combinators for operating with asynchronous I/O objects,
226 //! including ways to work with them using futures, streams and sinks.
227
228 pub use futures_io::{
229 Error, Initializer, IoVec, ErrorKind, AsyncRead, AsyncWrite, Result
230 };
231 pub use futures_util::io::{
232 AsyncReadExt, AsyncWriteExt, AllowStdIo, Close, CopyInto, Flush,
233 Read, ReadExact, ReadHalf, ReadToEnd, Window, WriteAll, WriteHalf,
234 };
235}
236
237#[cfg(feature = "std")]
238pub mod never {
239 //! This module contains the `Never` type.
240 //!
241 //! Values of this type can never be created and will never exist.
242 pub use futures_core::never::*;
243}
244
245pub mod prelude {
246 //! A "prelude" for crates using the `futures` crate.
247 //!
248 //! This prelude is similar to the standard library's prelude in that you'll
249 //! almost always want to import its entire contents, but unlike the standard
250 //! library's prelude you'll have to do so manually:
251 //!
252 //! ```
253 //! use futures::prelude::*;
254 //! ```
255 //!
256 //! The prelude may grow over time as additional items see ubiquitous use.
257
258 pub use futures_core::{
259 Future,
260 IntoFuture,
261 Stream,
262 Async,
263 Poll,
264 Never,
265 task,
266 };
267
268 #[cfg(feature = "std")]
269 pub use futures_core::executor::Executor;
270
271 #[cfg(feature = "nightly")]
272 pub use futures_stable::{
273 StableFuture,
274 StableStream
275 };
276
277 #[cfg(all(feature = "nightly", feature = "std"))]
278 pub use futures_stable::StableExecutor;
279
280 pub use futures_sink::Sink;
281
282 #[cfg(feature = "std")]
283 pub use futures_io::{
284 AsyncRead,
285 AsyncWrite,
286 };
287
288 pub use futures_util::{
289 FutureExt,
290 StreamExt,
291 SinkExt,
292 };
293
294 #[cfg(feature = "std")]
295 pub use futures_util::{
296 AsyncReadExt,
297 AsyncWriteExt,
298 };
299
300 #[cfg(feature = "nightly")]
301 pub use futures_macro_async::{
302 async,
303 async_stream,
304 async_block,
305 async_stream_block,
306 };
307
308 #[cfg(feature = "nightly")]
309 pub use futures_macro_await::{
310 await,
311 stream_yield,
312 await_item
313 };
314}
315
316pub mod sink {
317 //! Asynchronous sinks.
318 //!
319 //! This module contains:
320 //!
321 //! - The [`Sink` trait](::Sink), which allows you to asynchronously write data.
322 //!
323 //! - The [`SinkExt`](::sink::SinkExt) trait, which provides adapters
324 //! for chaining and composing sinks.
325
326 pub use futures_sink::Sink;
327
328 pub use futures_util::sink::{
329 Close, Fanout, Flush, Send, SendAll, SinkErrInto, SinkMapErr, With,
330 WithFlatMap, SinkExt,
331 };
332
333 #[cfg(feature = "std")]
334 pub use futures_util::sink::Buffer;
335}
336
337pub mod stream {
338 //! Asynchronous streams.
339 //!
340 //! This module contains:
341 //!
342 //! - The [`Stream` trait](::Stream), for objects that can asynchronously
343 //! produce a sequence of values.
344 //!
345 //! - The [`StreamExt`](::StreamExt) trait, which provides adapters
346 //! for chaining and composing streams.
347 //!
348 //! - Top-level stream contructors like [`iter_ok`](::stream::iter_ok) which
349 //! creates a stream from an iterator, and
350 //! [`futures_unordered`](::stream::futures_unordered()), which constructs a
351 //! stream from a collection of futures.
352
353 pub use futures_core::stream::Stream;
354
355 pub use futures_util::stream::{
356 AndThen, Chain, Concat, Empty, Filter, FilterMap, Flatten, Fold,
357 ForEach, Forward, ErrInto, Fuse, Inspect, InspectErr, IterOk,
358 IterResult, Map, MapErr, Once, OrElse, Peekable, PollFn, Repeat, Select,
359 Skip, SkipWhile, StreamFuture, Take, TakeWhile, Then, Unfold, Zip,
360 StreamExt, empty, iter_ok, iter_result, once, poll_fn, repeat, unfold,
361 };
362
363 #[cfg(feature = "std")]
364 pub use futures_util::stream::{
365 futures_unordered, select_all, BufferUnordered, Buffered, CatchUnwind, Chunks, Collect,
366 FuturesUnordered, FuturesOrdered, ReuniteError, SelectAll, SplitSink, SplitStream,
367 futures_ordered,
368 };
369}
370
371pub mod task {
372 //! Tools for working with tasks.
373 //!
374 //! This module contains:
375 //!
376 //! - [`Context`](::task::Context), which provides contextual data present
377 //! for every task, including a handle for waking up the task.
378 //!
379 //! - [`Waker`](::task::Waker), a handle for waking up a task.
380 //!
381 //! - [`LocalKey`](::task::LocalKey), a key for task-local data; you should
382 //! use the [`task_local` macro](../macro.task_local.html) to set up such keys.
383 //!
384 //! Tasks themselves are generally created by spawning a future onto [an
385 //! executor](::executor). However, you can manually construct a task by
386 //! creating your own `Context` instance, and polling a future with it.
387 //!
388 //! The remaining types and traits in the module are used for implementing
389 //! executors or dealing with synchronization issues around task wakeup.
390
391 pub use futures_core::task::{
392 Context, LocalMap, Waker, UnsafeWake,
393 };
394
395 #[cfg_attr(feature = "nightly", cfg(target_has_atomic = "ptr"))]
396 pub use futures_core::task::AtomicWaker;
397
398 #[cfg(feature = "std")]
399 pub use futures_core::task::{LocalKey, Wake};
400}
401
402#[cfg(feature = "nightly")]
403pub mod stable {
404 //! `async/await` futures which can be pinned to a particular location.
405 //!
406 //! This module contains:
407 //!
408 //! - The [`StableFuture`](::StableFuture) and [`StableStream`](::StableStream)
409 //! traits which allow for immovable, self-referential `Future`s and `Streams`.
410 //!
411 //! - The [`StableExecutor`](::StableExecutor) trait for `Executor`s which
412 //! take [`PinBox`](::std::boxed:PinBox)ed `Future`s.
413 //!
414 //! - A [`block_on_stable`](::block_on_stable) function for blocking on
415 //! `StableFuture`s.
416 //!
417 //! These immovable future types are most commonly used with the async/await
418 //! macros, which are included in the prelude. These macros can be used to
419 //! write asynchronous code in an ergonomic blocking style:
420 //!
421 //! ```rust
422 //! /// A simple async function which returns immediately once polled:
423 //! #[async]
424 //! fn foo() -> Result<i32, i32> {
425 //! Ok(1)
426 //! }
427 //!
428 //! /// Async functions can `await!` the result of other async functions:
429 //! #[async]
430 //! fn bar() -> Result<i32, i32> {
431 //! let foo_num = await!(foo())?;
432 //! Ok(foo_num + 5)
433 //! }
434 //!
435 //! /// Async functions can also choose to return a `Box`ed `Future` type.
436 //! /// To opt into `Send`able futures, use `#[async(boxed, send)]`.
437 //! #[async(boxed)]
438 //! fn boxed(x: i32) -> Result<i32, i32> {
439 //! Ok(
440 //! await!(foo())? + await!(bar()) + x
441 //! )
442 //! }
443 //!
444 //! /// Async expressions can also be written in `async_block!`s:
445 //! fn async_block() -> impl StableFuture<Item = i32, Error = i32> {
446 //! println!("Runs before the future is returned");
447 //! async_block! {
448 //! println!("Runs the first time the future is polled");
449 //! Ok(5)
450 //! }
451 //! }
452 //!
453 //! /// The futures that result from async functions can be pinned and used
454 //! /// with other `Future` combinators:
455 //! #[async]
456 //! fn join_two_futures() -> Result<(i32, i32), i32> {
457 //! let joined = foo().pin().join(bar().pin());
458 //! await!(joined)
459 //! }
460 //!
461 //! /// Streams can also be written in this style using the
462 //! /// `#[async_stream(item = ItemType)]` macro. The `stream_yield!`
463 //! /// macro is used to yield elements, and the `async_stream_block!`
464 //! /// macro can be used to write async streams inside other functions:
465 //! #[async_stream(boxed, send, item = u64)]
466 //! fn stream_boxed() -> Result<(), i32> {
467 //! let foo_result = await!(foo())?;
468 //! stream_yield!(foo_result as u64);
469 //! stream_yield!(22);
470 //! Ok(())
471 //! }
472 //!
473 //! /// Finally #[async] can be used on `for` loops to loop over the results
474 //! /// of a stream:
475 //! #[async]
476 //! fn async_for() -> Result<(), i32> {
477 //! #[async]
478 //! for i in stream_boxed() {
479 //! println!("yielded {}", i);
480 //! }
481 //! Ok(())
482 //! }
483 //! ```
484
485 pub use futures_stable::{StableFuture, StableStream};
486
487 #[cfg(feature = "std")]
488 pub use futures_stable::{StableExecutor, block_on_stable};
489}
490
491#[cfg(feature = "nightly")]
492#[doc(hidden)]
493pub mod __rt {
494 #[cfg(feature = "std")]
495 pub extern crate std;
496 pub use futures_async_runtime::*;
497}