- Fixed unsoundness in
MappedMutexGuard
(#2240) - Re-exported
TakeUntil
(#2235) - futures-test: Prevent double panic in
panic_waker
(#2236)
- Fixed UB due to missing 'static on
task::waker
(#2206) - Added
AsyncBufReadExt::fill_buf
(#2225) - Added
TryStreamExt::try_take_while
(#2212) - Added
is_connected_to
method tompsc::{Sender, UnboundedSender}
(#2179) - Added
is_connected_to
method tooneshot::Sender
(#2158) - Implement
FusedStream
forFuturesOrdered
(#2205) - Fixed documentation links
- Improved documentation
- futures-test: Added
track_closed
method toAsyncWriteTestExt
andSinkTestExt
(#2159) - futures-test: Implemented more traits for
InterleavePending
(#2208) - futures-test: Implemented more traits for
AssertUnmoved
(#2208)
- Added
StreamExt::flat_map
. - Added
StreamExt::ready_chunks
. - Added
*_unpin
methods toSinkExt
. - Added a
cancellation()
future tooneshot::Sender
. - Added
reunite
method toReadHalf
andWriteHalf
. - Added
Extend
implementations forFutures(Un)Ordered
andSelectAll
. - Added support for reexporting the
join!
andselect!
macros. - Added
no_std
support for thepending!
andpoll!
macros. - Added
Send
andSync
support forAssertUnmoved
. - Fixed a bug where
Shared
wasn't relinquishing control to the executor. - Removed the
Send
bound on the output ofRemoteHandle
. - Relaxed bounds on
FuturesUnordered
. - Reorganized internal tests to work under different
--feature
s. - Reorganized the bounds on
StreamExt::forward
. - Removed and replaced a large amount of internal
unsafe
.
- Fixed missing
Drop
forUnboundedReceiver
(#2064)
- Fixed compatibility issue with pinned facade (#2062)
- Improved buffering performance of
SplitSink
(#1969) - Added
select_biased!
macro (#1976) - Added
hash_receiver
method to mpsc channel (#1962) - Added
stream::try_unfold
(#1977) - Fixed bug with zero-size buffers in vectored IO (#1998)
AtomicWaker::new()
is nowconst fn
(#2007)- Fixed bug between threadpool and user park/unparking (#2010)
- Added
stream::Peakable::peek
(#2021) - Added
StreamExt::scan
(#2044) - Added impl of
AsyncRead
/Write
forBufReader
/Writer
(#2033) - Added impl of
Spawn
andLocalSpawn
forArc<impl Spawn
andRc<impl Spawn>
(#2039) - Fixed
Sync
issues withFuturesUnordered
(#2054) - Added
into_inner
method forfuture::Ready
(#2055) - Added
MappedMutexGuard
API (#2056) - Mitigated starvation issues in
FuturesUnordered
(#2049) - Added
TryFutureExt::map_ok_or_else
(#2058)
- Fix signature of
LocalSpawn
trait (breaking change -- see #1959)
- Stable release along with stable async/await!
- Added async/await to default features (#1953)
- Changed
Spawn
trait andFuturesUnordered::push
to take&self
(#1950) - Moved
Spawn
andFutureObj
out offutures-core
and intofutures-task
(#1925) - Changed case convention for feature names (#1937)
- Added
executor
feature (#1949) - Moved
copy_into
/copy_buf_into
(#1948) - Changed
SinkExt::send_all
to accept aTryStream
(#1946) - Removed
ThreadPool::run
(#1944) - Changed to use our own definition of
io::Cursor
(#1943) - Removed
BufReader::poll_seek_relative
(#1938) - Changed
skip
to take ausize
rather thanu64
(#1931) - Removed
Stream
impl forVecDeque
(#1930) - Renamed
Peekable::peek
topoll_peek
(#1928) - Added immutable iterators for
FuturesUnordered
(#1922) - Made
ThreadPool
optional (#1910) - Renamed
oneshot::Sender::poll_cancel
topoll_canceled
(#1908) - Added some missing
Clone
implementations - Documentation fixes
- Stabilized the
async-await
feature (#1816) - Made
async-await
feature no longer requirestd
feature (#1815) - Updated
proc-macro2
,syn
, andquote
to 1.0 (#1798) - Exposed unstable
BiLock
(#1827) - Renamed "nightly" feature to "unstable" (#1823)
- Moved to our own
io::{Empty, Repeat, Sink}
(#1829) - Made
AsyncRead::initializer
API unstable (#1845) - Moved the
Never
type fromfutures-core
tofutures-util
(#1836) - Fixed use-after-free on panic in
ArcWake::wake_by_ref
(#1797) - Added
AsyncReadExt::chain
(#1810) - Added
Stream::size_hint
(#1853) - Added some missing
FusedFuture
(#1868) andFusedStream
implementations (#1831) - Added a
From
impl forMutex
(#1839) - Added
Mutex::{get_mut, into_inner}
(#1839) - Re-exported
TryConcat
andTryFilter
(#1814) - Lifted
Unpin
bound and implementedAsyncBufRead
forio::Take
(#1821) - Lifted
Unpin
bounds onget_pin_mut
(#1820) - Changed
SendAll
to flush theSink
when the sourceStream
is pending (#1877) - Set default threadpool size to one if
num_cpus::get()
returns zero (#1835) - Removed dependency on
rand
by using our own PRNG (#1837) - Removed
futures-core
dependency fromfutures-sink
(#1832)
- Rewrote
join!
andtry_join!
as procedural macros to allow passing expressions (#1783) - Banned manual implementation of
TryFuture
andTryStream
for forward compatibility. See #1776 for more details. (#1777) - Changed
AsyncReadExt::read_to_end
to return the total number of bytes read (#1721) - Changed
ArcWake::into_waker
to a free functionwaker
(#1676) - Supported trailing commas in macros (#1733)
- Removed futures-channel dependency from futures-executor (#1735)
- Supported
channel::oneshot
in no_std environment (#1749) - Added
Future
bounds toFusedFuture
(#1779) - Added
Stream
bounds toFusedStream
(#1779) - Changed
StreamExt::boxed
to returnBoxStream
(#1780) - Added
StreamExt::boxed_local
(#1780) - Added
AsyncReadExt::read_to_string
(#1721) - Implemented
AsyncWrite
forIntoAsyncRead
(#1734) - Added get_ref, get_mut and into_inner methods to
Compat01As03
andCompat01As03Sink
(#1705) - Added
ThreadPool::{spawn_ok, spawn_obj_ok}
(#1750) - Added
TryStreamExt::try_flatten
(#1731) - Added
FutureExt::now_or_never
(#1747)
- Removed
try_ready!
macro in favor ofready!(..)?
. (#1602) - Removed
io::Window::{set_start, set_end}
in favor ofio::Window::set
. (#1667) - Re-exported
pin_utils::pin_mut!
macro. (#1686) - Made all extension traits unnamed in the prelude. (#1662)
- Allowed
?Sized
types in some methods and structs. (#1647) - Added
Send + Sync
bounds toArcWake
trait to fix unsoundness. (#1654) - Changed
AsyncReadExt::copy_into
to consumeself
. (#1674) - Renamed
future::empty
topending
. (#1689) - Added
#[must_use]
to some combinators. (#1600) - Added
AsyncWriteExt::{write, write_vectored}
. (#1612) - Added
AsyncReadExt::read_vectored
. (#1612) - Added
TryFutureExt::try_poll_unpin
. (#1613) - Added
TryFutureExt::try_flatten_stream
. (#1618) - Added
io::BufWriter
. (#1608) - Added
Sender::same_receiver
andUnboundedSender::same_receiver
. (#1617) - Added
future::try_select
. (#1622) - Added
TryFutureExt::{inspect_ok, inspect_err}
. (#1630) - Added
Compat::get_ref
. (#1648) - Added
io::Window::set
. (#1667) - Added
AsyncWriteExt::into_sink
. (#1675) - Added
AsyncBufReadExt::copy_buf_into
. (#1674) - Added
stream::pending
. (#1689) - Implemented
std::error::Error
forSpawnError
. (#1604) - Implemented
Stream
forFlattenSink
. (#1651) - Implemented
Sink
forTryFlattenStream
. (#1651) - Implemented
AsyncRead
,AsyncWrite
,AsyncSeek
,AsyncBufRead
,FusedFuture
andFusedStream
for Either. (#1695) - Replaced empty enums with
Never
type, an alias forcore::convert::Infallible
. - Removed the
futures-channel
dependency fromfutures-sink
and makefutures-sink
an optional dependency offutures-channel
. - Renamed
Sink::SinkError
toSink::Error
. - Made a number of dependencies of
futures-util
optional.
- Updated to new nightly
async_await
. - Changed
AsyncRead::poll_vectored_read
andAsyncWrite::poll_vectored_write
to use stabilizedstd::io::{IoSlice, IoSliceMut}
instead ofiovec::IoVec
, and renamed toAsyncRead::poll_read_vectored
andAsyncWrite::poll_write_vectored
. - Added
LocalBoxFuture
andFutureExt::boxed_local
. - Added
TryStreamExt::{try_filter, inspect_ok, inspect_err}
. - Added
try_future::select_ok
. - Added
AsyncBufReadExt::{read_line, lines}
. - Added
io::BufReader
.
- Updated to stabilized
futures_api
. - Removed
StreamObj
, cautioned against usage ofFutureObj
. - Changed
StreamExt::select
to a function. - Added
AsyncBufRead
andAsyncSeek
traits. - Expanded trait impls to include more pinned pointers and ?Sized types.
- Added
future::Fuse::terminated
constructor. - Added
never_error
combinator. - Added
StreamExt::enumerate
. - Re-added
TryStreamExt::{and_then, or_else}
. - Added functions to partially progress a local pool.
- Changed to use our own
Either
type rather than the one from theeither
crate.
- Updated to new nightly
futures_api
. - Changed
Forward
combinator to drop sink after completion, and allow!Unpin
Sink
s. - Added 0.1 <-> 0.3 compatability shim for
Sink
s. - Changed
Sink::Item
to a generic parameterSink<Item>
, allowingSink
s to accept multiple different types, including types containing references. - Changed
AsyncRead
andAsyncWrite
to takePin<&mut Self>
rather than&mut self
. - Added support for
no_std
+alloc
use. - Changed
join
andtry_join
combinators to functions. - Fixed propagation of
cfg-target-has-atomic
feature.
- Updated to new nightly with stabilization candidate API.
- Removed
LocalWaker
. - Added
#[must_use]
toStream
andSink
traits. - Enabled using
!Unpin
futures inJoinAll
. - Added the
try_join_all
combinator. - Stopped closing a whole channel upon closing of one sender.
- Removed
TokioDefaultSpawner
andtokio-compat
. - Moved intra-crate dependencies to exact versions.
- Updated to new nightly with a modification to
Pin::set
. - Expose
AssertUnmoved
andPendingOnce
. - Prevent double-panic in
AssertUnmoved
. - Support nested invocations of the
select!
macro. - Implement
Default
forMutex
andSelectAll
.
- Updated to newly stabilized versions of the
pin
andarbitrary_self_types
features. - Re-added
select_all
for streams. - Added
TryStream::into_async_read
for converting from a stream of bytes into anAsyncRead
. - Added
try_poll_next_unpin
. - Rewrote
select!
as a procedural macro for better error messages - Exposed
join_all
from the facade
- Revamped
select!
macro - Added
select_next_some
method for getting only theSome
elements of a stream fromselect!
- Added
futures::lock::Mutex
for async-aware synchronization. - Fixed bug converting
Pin<Box<_>>
toStreamObj
- Improved performance of futures::channel
- Improved performance and documentation of
Shared
- Add
new
method and morederive
s to theCompat
type - Enabled spawning on a borrowed threadpool
- Re-added
join_all
- Added
try_concat
- Fixed in response to new nightly handling of 2018 edition +
#![no_std]
- Fixed stack overflow in 0.1 compatibility layer
- Added AsyncRead / AsyncWrite compatibility layer
- Added Spawn -> 0.1 Executor compatibility
- Made 0.1 futures usable on 0.3 executors without an additional global
Task
, accomplished by wrapping 0.1 futures in an 0.1Spawn
when using them as 0.3 futures. - Cleanups and improvments to the
AtomicWaker
implementation.
- Update to new nightly which removes
Spawn
fromtask::Context
and replacesContext
withLocalWaker
. - Add
Spawn
andLocalSpawn
traits andFutureObj
andLocalFutureObj
types tofutures-core
.
- Replace usage of
crate
visibility withpub(crate)
now thatcrate
visibility is no longer included in the 2018 edition - Remove newly-stabilized "edition" feature in Cargo.toml files
- Revert usage of cargo crate renaming feature
Note: This release does not work, use 0.3.0-alpha.5
instead
future::ok
andfuture:err
to create result wrapping futures (similar tofuture::ready
)futures-test
crate with testing utilitiesStreamExt::boxed
combinator- Unsoundness fix for
FuturesUnordered
StreamObj
(similar toFutureObj
)- Code examples for compatiblity layer functions
- Use cargo create renaming feature to import
futures@0.1
for compatiblily layer - Import pinning APIs from
core::pin
- Run Clippy in CI only when it is available
- Compatibilty with newest nightly
- Futures 0.1 compatibility layer including Tokio compatibility
- Added
spawn!
andspawn_with_handle!
macros - Added
SpawnExt
methodsspawn
andspawn_with_handle
- Extracted pin macros into
pin_utils
crate - Added
FutureExt
combinatorsboxed
andunit_error
- Remove prelude from all doc examples (The prelude is still recommended for usage in playground examples. However, for doc examples we determined that fully expanded imports are more helpful)
- Improvements to
select!
andjoin!
macros - Added
try_join!
macro - Added
StreamExt
combinator methodstry_join
andfor_each_concurrent
- Added
TryStreamExt
combinator methodsinto_stream
,try_filter_map
,try_skip_while
,try_for_each_concurrent
andtry_buffer_unordered
- Fix stream termination bug in
StreamExt::buffered
andStreamExt::buffer_unordered
- Added docs for
StreamExt::buffered
,StreamExt::buffer_unordered
- Added
task::local_waker_ref_from_nonlocal
andtask::local_waker_ref
functions - CI improvements
- Doc improvements to
StreamExt::select
- The changelog is back!
- Compatiblity with futures API in latest nightly
- Code examples and doc improvements
- IO: Methods of traits
AsyncReadExt
,AsyncWriteExt
- Future:
- Methods of trait
TryFutureExt
- Free functions
empty
,lazy
,maybe_done
,poll_fn
andready
- Type
FutureOption
- Macros
join!
,select!
andpending!
- Methods of trait
- Stream: Methods of trait
TryStreamExt
- IO: Methods of traits
- Added
TryStreamExt
combinatorsmap_ok
,map_err
,err_into
,try_next
andtry_for_each
- Added
Drain
, a sink that will discard all items given to it. Can be created using thedrain
function - Bugfix for the
write_all
combinator AsyncWrite
impl forCursor<T: AsMut<[u8]>>
FuturesUnordered
optimization: Since the context stores a&LocalWaker
reference, it was possible to avoid cloning theArc
of the waker- Futures-rs now uses Clippy
- We now use in-band lifetimes
- The
join!
andselect!
macros are now exposed by thefutures
crate - The project logo was added to the
README.md
sink::MapErr::get_pinned_mut
is now calledget_pin_mut
- We now use the unstable
use_extern_macros
feature for macro reexports - CI improvements: Named CI jobs, tests are now run on macOS and Linux, the docs are generated and Clippy needs to pass
#[deny(warnings)]
was removed from all crates and is now only enforced in the CI- We now have a naming convention for type paramters:
Fut
future,F
function,St
stream,Si
sink,S
sink & stream,R
reader,W
writer,T
value,E
error - "Task" is now defined as our term for "lightweight thread". The code of the executors and
FuturesUnordered
was refactored to align with this definition.
- Major changes: See the announcement on our new blog for details. The changes are too numerous to be covered in this changelog because nearly every line of code was modified.
- Add a
close
method onsink::Wait
- Undeprecate
stream::iter
asstream::iter_result
- Improve performance of wait-related methods
- Tweak buffered sinks with a 0 capacity to forward directly to the underlying sink.
- Add
FromIterator
implementation forFuturesOrdered
andFuturesUnordered
.
- A
prelude
module has been added to glob import from and pick up a whole bunch of useful types sync::mpsc::Sender::poll_ready
has been added as an APIsync::mpsc::Sender::try_send
has been added as an API
- Improve performance of
BiLock
methods - Implement
Clone
forFutureResult
- Forward
Stream
trait throughSinkMapErr
- Add
stream::futures_ordered
next tofutures_unordered
- Reimplement
Stream::buffered
on top ofstream::futures_ordered
(much more efficient at scale). - Add a
with_notify
function for abstractions which previously requiredUnparkEvent
. - Add
get_ref
/get_mut
/into_inner
functions for stream take/skip methods - Add a
Clone
implementation forSharedItem
andSharedError
- Add a
mpsc::spawn
function to spawn aStream
into anExecutor
- Add a
reunite
function forBiLock
and the split stream/sink types to rejoin two halves and reclaim the original item. - Add
stream::poll_fn
to behave similarly tofuture::poll_fn
- Add
Sink::with_flat_map
likeIterator::flat_map
- Bump the minimum Rust version to 1.13.0
- Expose
AtomicTask
in the public API for managing synchronization around task notifications. - Unify the
Canceled
type of thesync
andunsync
modules. - Deprecate the
boxed
methods. These methods have caused more confusion than they've solved historically, so it's recommended to use a local extension trait or a local helper instead of the trait-based methods. - Deprecate the
Stream::merge
method as it's less ergonomic thanselect
. - Add
oneshot::Sender::is_canceled
to test if a oneshot is canceled off a task. - Deprecates
UnboundedSender::send
in favor of a method namedunbounded_send
to avoid a conflict withSink::send
. - Deprecate the
stream::iter
function in favor of anstream::iter_ok
adaptor to avoid the need to deal withResult
manually. - Add an
inspect
function to theFuture
andStream
traits along the lines ofIterator::inspect
This is a relatively large release of the futures
crate, although much of it
is from reworking internals rather than new APIs. The banner feature of this
release is that the futures::{task, executor}
modules are now available in
no_std
contexts! A large refactoring of the task system was performed in
PR #436 to accommodate custom memory allocation schemes and otherwise remove
all dependencies on std
for the task module. More details about this change
can be found on the PR itself.
Other API additions in this release are:
- A
FuturesUnordered::push
method was added and theFuturesUnordered
type itself was completely rewritten to efficiently track a large number of futures. - A
Task::will_notify_current
method was added with a slightly different implementation thanTask::is_current
but with stronger guarantees and documentation wording about its purpose. - Many combinators now have
get_ref
,get_mut
, andinto_inner
methods for accessing internal futures and state. - A
Stream::concat2
method was added which should be considered the "fixed" version ofconcat
, this one doesn't panic on empty streams. - An
Executor
trait has been added to represent abstracting over the concept of spawning a new task. Crates which only need the ability to spawn a future can now be generic overExecutor
rather than requiring atokio_core::reactor::Handle
.
As with all 0.1.x releases this PR is intended to be 100% backwards compatible. All code that previously compiled should continue to do so with these changes. As with other changes, though, there are also some updates to be aware of:
- The
task::park
function has been renamed totask::current
. - The
Task::unpark
function has been renamed toTask::notify
, and in general terminology around "unpark" has shifted to terminology around "notify" - The
Unpark
trait has been deprecated in favor of theNotify
trait mentioned above. - The
UnparkEvent
structure has been deprecated. It currently should perform the same as it used to, but it's planned that in a future 0.1.x release the performance will regress for crates that have not transitioned away. The primary primitive to replace this is the addition of apush
function on theFuturesUnordered
type. If this does not help implement your use case though, please let us know! - The
Task::is_current
method is now deprecated, and you likely want to useTask::will_notify_current
instead, but let us know if this doesn't suffice!
- Add forwarding sink/stream impls for
stream::FromErr
andsink::SinkFromErr
- Add
PartialEq
andEq
tompsc::SendError
- Reimplement
Shared
withspawn
instead ofUnparkEvent
- Add
Stream::from_err
andSink::from_err
- Allow
SendError
to beClone
when possible
The major highlight of this release is the addition of a new "default" method on
the Sink
trait, Sink::close
. This method is used to indicate to a sink that
no new values will ever need to get pushed into it. This can be used to
implement graceful shutdown of protocols and otherwise simply indicates to a
sink that it can start freeing up resources.
Currently this method is not a default method to preserve backwards
compatibility, but it's intended to become a default method in the 0.2 series of
the futures
crate. It's highly recommended to audit implementations of Sink
to implement the close
method as is fit.
Other changes in this release are:
- A new select combinator,
Future::select2
was added for a heterogeneous select. - A
Shared::peek
method was added to check to see if it's done. Sink::map_err
was implemented- The
log
dependency was removed - Implementations of the
Debug
trait are now generally available. - The
stream::IterStream
type was renamed tostream::Iter
(with a reexport for the old name). - Add a
Sink::wait
method which returns an adapter to use an arbitrarySink
synchronously. - A
Stream::concat
method was added to concatenate a sequence of lists. - The
oneshot::Sender::complete
method was renamed tosend
and now returns aResult
indicating successful transmission of a message or not. Note that thecomplete
method still exists, it's just deprecated.
- Add a new
unsync
module which mirrorssync
to the extent that it can but is intended to not perform cross-thread synchronization (only usable within one thread). - Tweak
Shared
to work when handles may not get poll'd again.
- Fix
Send/Sync
of a few types - Add
future::tail_fn
for more easily writing loops - Export SharedItem/SharedError
- Remove an unused type parameter in
from_err
- Fix some race conditions in the
Shared
implementation - Add
Stream::take_while
- Fix an unwrap in
stream::futures_unordered
- Generalize
Stream::for_each
- Add
Stream::chain
- Add
stream::repeat
- Relax
&mut self
to&self
inUnboundedSender::send
- Add a
Future::shared
method for creating a future that can be shared amongst threads by cloning the future itself. All derivative futures will resolve to the same value once the original future has been resolved. - Add a
FutureFrom
trait for future-based conversion - Fix a wakeup bug in
Receiver::close
- Add
future::poll_fn
for quickly adapting aPoll
-based function to a future. - Add an
Either
enum with two branches to easily create one future type based on two different futures created on two branches of control flow. - Remove the
'static
bound onUnpark
- Optimize
send_all
andforward
to send as many items as possible before callingpoll_complete
. - Unify the return types of the
ok
,err
, andresult
future to assist returning different varieties in different branches of a function. - Add
CpuFuture::forget
to allow the computation to continue running after a drop. - Add a
stream::futures_unordered
combinator to turn a list of futures into a stream representing their order of completion.
- Fix
Clone
bound on the type parameter onUnboundedSender
- Fix
#![no_std]
support
This is quite a large release relative to the previous point releases! As with all 0.1 releases, this release should be fully compatible with the 0.1.3 release. If any incompatibilities are discovered please file an issue!
The largest changes in 0.1.4 are the addition of a Sink
trait coupled with a
reorganization of this crate. Note that all old locations for types/traits
still exist, they're just deprecated and tagged with #[doc(hidden)]
.
The new Sink
trait is used to represent types which can periodically over
time accept items, but may take some time to fully process the item before
another can be accepted. Essentially, a sink is the opposite of a stream. This
trait will then be used in the tokio-core crate to implement simple framing by
modeling I/O streams as both a stream and a sink of frames.
The organization of this crate is to now have three primary submodules,
future
, stream
, and sink
. The traits as well as all combinator types are
defined in these submodules. The traits and types like Async
and Poll
are
then reexported at the top of the crate for convenient usage. It should be a
relatively rare occasion that the modules themselves are reached into.
Finally, the 0.1.4 release comes with a new module, sync
, in the futures
crate. This is intended to be the home of a suite of futures-aware
synchronization primitives. Currently this is inhabited with a oneshot
module
(the old oneshot
function), a mpsc
module for a new multi-producer
single-consumer channel, and a BiLock
type which represents sharing ownership
of one value between two consumers. This module may expand over time with more
types like a mutex, rwlock, spsc channel, etc.
Notable deprecations in the 0.1.4 release that will be deleted in an eventual 0.2 release:
- The
TaskRc
type is now deprecated in favor ofBiLock
or otherwiseArc
sharing. - All future combinators should be accessed through the
future
module, not the top-level of the crate. - The
Oneshot
andComplete
types are now replaced with thesync::oneshot
module. - Some old names like
collect
are deprecated in favor of more appropriately named versions likejoin_all
- The
finished
constructor is nowok
. - The
failed
constructor is nowerr
. - The
done
constructor is nowresult
.
As always, please report bugs to https://github.com/rust-lang-nursery/futures-rs and we always love feedback! If you've got situations we don't cover, combinators you'd like to see, or slow code, please let us know!
Full changelog:
- Improve scalability of
buffer_unordered
combinator - Fix a memory ordering bug in oneshot
- Add a new trait,
Sink
- Reorganize the crate into three primary modules
- Add a new
sync
module for synchronization primitives - Add a
BiLock
sync primitive for two-way sharing - Deprecate
TaskRc
- Rename
collect
tojoin_all
- Use a small vec in
Events
for improved clone performance - Add
Stream::select
for selecting items from two streams likemerge
but requiring the same types. - Add
stream::unfold
constructor - Add a
sync::mpsc
module with a futures-aware multi-producer single-consumer queue. Both bounded (with backpressure) and unbounded (no backpressure) variants are provided. - Renamed
failed
,finished
, anddone
combinators toerr
,ok
, andresult
. - Add
Stream::forward
to send all items to a sink, likeSink::send_all
- Add
Stream::split
for streams which are both sinks and streams to have separate ownership of the stream/sink halves - Improve
join_all
with concurrency
- Rewrite
oneshot
for efficiency and removing allocations on send/recv - Errors are passed through in
Stream::take
andStream::skip
- Add a
select_ok
combinator to pick the first of a list that succeeds - Remove the unnecessary
SelectAllNext
typedef - Add
Stream::chunks
for receiving chunks of data - Rewrite
stream::channel
for efficiency, correctness, and removing allocations - Remove
Send + 'static
bounds on thestream::Empty
type
- Fixed a bug in drop of
FutureSender
- Expose the channel
SendError
type - Add
Future::into_stream
to convert to a single-element stream - Add
Future::flatten_to_stream
to convert a future of a stream to a stream - impl Debug for SendError
- Add stream::once for a one element stream
- Accept IntoIterator in stream::iter
- Add
Stream::catch_unwind
Initial release!