Future-proof the Futures API

This commit is contained in:
Taylor Cramer 2019-03-11 16:56:00 -07:00
parent 20dbf28624
commit 1691e06db6
11 changed files with 176 additions and 70 deletions

View File

@ -81,7 +81,7 @@ use core::ops::{
CoerceUnsized, DispatchFromDyn, Deref, DerefMut, Receiver, Generator, GeneratorState CoerceUnsized, DispatchFromDyn, Deref, DerefMut, Receiver, Generator, GeneratorState
}; };
use core::ptr::{self, NonNull, Unique}; use core::ptr::{self, NonNull, Unique};
use core::task::{Waker, Poll}; use core::task::{Context, Poll};
use crate::vec::Vec; use crate::vec::Vec;
use crate::raw_vec::RawVec; use crate::raw_vec::RawVec;
@ -914,7 +914,7 @@ impl<G: ?Sized + Generator> Generator for Pin<Box<G>> {
impl<F: ?Sized + Future + Unpin> Future for Box<F> { impl<F: ?Sized + Future + Unpin> Future for Box<F> {
type Output = F::Output; type Output = F::Output;
fn poll(mut self: Pin<&mut Self>, waker: &Waker) -> Poll<Self::Output> { fn poll(mut self: Pin<&mut Self>, cx: &mut Context<'_>) -> Poll<Self::Output> {
F::poll(Pin::new(&mut *self), waker) F::poll(Pin::new(&mut *self), cx)
} }
} }

View File

@ -5,7 +5,7 @@
use marker::Unpin; use marker::Unpin;
use ops; use ops;
use pin::Pin; use pin::Pin;
use task::{Poll, Waker}; use task::{Context, Poll};
/// A future represents an asynchronous computation. /// A future represents an asynchronous computation.
/// ///
@ -44,8 +44,9 @@ pub trait Future {
/// Once a future has finished, clients should not `poll` it again. /// Once a future has finished, clients should not `poll` it again.
/// ///
/// When a future is not ready yet, `poll` returns `Poll::Pending` and /// When a future is not ready yet, `poll` returns `Poll::Pending` and
/// stores a clone of the [`Waker`] to be woken once the future can /// stores a clone of the [`Waker`] copied from the current [`Context`].
/// make progress. For example, a future waiting for a socket to become /// This [`Waker`] is then woken once the future can make progress.
/// For example, a future waiting for a socket to become
/// readable would call `.clone()` on the [`Waker`] and store it. /// readable would call `.clone()` on the [`Waker`] and store it.
/// When a signal arrives elsewhere indicating that the socket is readable, /// When a signal arrives elsewhere indicating that the socket is readable,
/// `[Waker::wake]` is called and the socket future's task is awoken. /// `[Waker::wake]` is called and the socket future's task is awoken.
@ -88,16 +89,17 @@ pub trait Future {
/// ///
/// [`Poll::Pending`]: ../task/enum.Poll.html#variant.Pending /// [`Poll::Pending`]: ../task/enum.Poll.html#variant.Pending
/// [`Poll::Ready(val)`]: ../task/enum.Poll.html#variant.Ready /// [`Poll::Ready(val)`]: ../task/enum.Poll.html#variant.Ready
/// [`Context`]: ../task/struct.Context.html
/// [`Waker`]: ../task/struct.Waker.html /// [`Waker`]: ../task/struct.Waker.html
/// [`Waker::wake`]: ../task/struct.Waker.html#method.wake /// [`Waker::wake`]: ../task/struct.Waker.html#method.wake
fn poll(self: Pin<&mut Self>, waker: &Waker) -> Poll<Self::Output>; fn poll(self: Pin<&mut Self>, cx: &mut Context<'_>) -> Poll<Self::Output>;
} }
impl<F: ?Sized + Future + Unpin> Future for &mut F { impl<F: ?Sized + Future + Unpin> Future for &mut F {
type Output = F::Output; type Output = F::Output;
fn poll(mut self: Pin<&mut Self>, waker: &Waker) -> Poll<Self::Output> { fn poll(mut self: Pin<&mut Self>, cx: &mut Context<'_>) -> Poll<Self::Output> {
F::poll(Pin::new(&mut **self), waker) F::poll(Pin::new(&mut **self), cx)
} }
} }
@ -108,7 +110,7 @@ where
{ {
type Output = <<P as ops::Deref>::Target as Future>::Output; type Output = <<P as ops::Deref>::Target as Future>::Output;
fn poll(self: Pin<&mut Self>, waker: &Waker) -> Poll<Self::Output> { fn poll(self: Pin<&mut Self>, cx: &mut Context<'_>) -> Poll<Self::Output> {
Pin::get_mut(self).as_mut().poll(waker) Pin::get_mut(self).as_mut().poll(cx)
} }
} }

View File

@ -8,4 +8,4 @@ mod poll;
pub use self::poll::Poll; pub use self::poll::Poll;
mod wake; mod wake;
pub use self::wake::{Waker, RawWaker, RawWakerVTable}; pub use self::wake::{Context, Waker, RawWaker, RawWakerVTable};

View File

@ -3,7 +3,7 @@
issue = "50547")] issue = "50547")]
use fmt; use fmt;
use marker::Unpin; use marker::{PhantomData, Unpin};
/// A `RawWaker` allows the implementor of a task executor to create a [`Waker`] /// A `RawWaker` allows the implementor of a task executor to create a [`Waker`]
/// which provides customized wakeup behavior. /// which provides customized wakeup behavior.
@ -36,6 +36,10 @@ impl RawWaker {
/// The `vtable` customizes the behavior of a `Waker` which gets created /// The `vtable` customizes the behavior of a `Waker` which gets created
/// from a `RawWaker`. For each operation on the `Waker`, the associated /// from a `RawWaker`. For each operation on the `Waker`, the associated
/// function in the `vtable` of the underlying `RawWaker` will be called. /// function in the `vtable` of the underlying `RawWaker` will be called.
#[rustc_promotable]
#[unstable(feature = "futures_api",
reason = "futures in libcore are unstable",
issue = "50547")]
pub const fn new(data: *const (), vtable: &'static RawWakerVTable) -> RawWaker { pub const fn new(data: *const (), vtable: &'static RawWakerVTable) -> RawWaker {
RawWaker { RawWaker {
data, data,
@ -63,21 +67,105 @@ pub struct RawWakerVTable {
/// required for this additional instance of a [`RawWaker`] and associated /// required for this additional instance of a [`RawWaker`] and associated
/// task. Calling `wake` on the resulting [`RawWaker`] should result in a wakeup /// task. Calling `wake` on the resulting [`RawWaker`] should result in a wakeup
/// of the same task that would have been awoken by the original [`RawWaker`]. /// of the same task that would have been awoken by the original [`RawWaker`].
pub clone: unsafe fn(*const ()) -> RawWaker, clone: unsafe fn(*const ()) -> RawWaker,
/// This function will be called when `wake` is called on the [`Waker`]. /// This function will be called when `wake` is called on the [`Waker`].
/// It must wake up the task associated with this [`RawWaker`]. /// It must wake up the task associated with this [`RawWaker`].
/// ///
/// The implemention of this function must not consume the provided data /// The implemention of this function must not consume the provided data
/// pointer. /// pointer.
pub wake: unsafe fn(*const ()), wake: unsafe fn(*const ()),
/// This function gets called when a [`RawWaker`] gets dropped. /// This function gets called when a [`RawWaker`] gets dropped.
/// ///
/// The implementation of this function must make sure to release any /// The implementation of this function must make sure to release any
/// resources that are associated with this instance of a [`RawWaker`] and /// resources that are associated with this instance of a [`RawWaker`] and
/// associated task. /// associated task.
pub drop: unsafe fn(*const ()), drop: unsafe fn(*const ()),
}
impl RawWakerVTable {
/// Creates a new `RawWakerVTable` from the provided `clone`, `wake`, and
/// `drop` functions.
///
/// # `clone`
///
/// This function will be called when the [`RawWaker`] gets cloned, e.g. when
/// the [`Waker`] in which the [`RawWaker`] is stored gets cloned.
///
/// The implementation of this function must retain all resources that are
/// required for this additional instance of a [`RawWaker`] and associated
/// task. Calling `wake` on the resulting [`RawWaker`] should result in a wakeup
/// of the same task that would have been awoken by the original [`RawWaker`].
///
/// # `wake`
///
/// This function will be called when `wake` is called on the [`Waker`].
/// It must wake up the task associated with this [`RawWaker`].
///
/// The implemention of this function must not consume the provided data
/// pointer.
///
/// # `drop`
///
/// This function gets called when a [`RawWaker`] gets dropped.
///
/// The implementation of this function must make sure to release any
/// resources that are associated with this instance of a [`RawWaker`] and
/// associated task.
#[rustc_promotable]
#[unstable(feature = "futures_api",
reason = "futures in libcore are unstable",
issue = "50547")]
pub const fn new(
clone: unsafe fn(*const ()) -> RawWaker,
wake: unsafe fn(*const ()),
drop: unsafe fn(*const ()),
) -> Self {
Self {
clone,
wake,
drop,
}
}
}
/// The `Context` of an asynchronous task.
///
/// Currently, `Context` only serves to provide access to a `&Waker`
/// which can be used to wake the current task.
pub struct Context<'a> {
waker: &'a Waker,
// Ensure we future-proof against variance changes by forcing
// the lifetime to be invariant (argument-position lifetimes
// are contravariant while return-position lifetimes are
// covariant).
_marker: PhantomData<fn(&'a ()) -> &'a ()>,
}
impl<'a> Context<'a> {
/// Create a new `Context` from a `&Waker`.
#[inline]
pub fn from_waker(waker: &'a Waker) -> Self {
Context {
waker,
_marker: PhantomData,
}
}
/// Returns a reference to the `Waker` for the current task.
#[inline]
pub fn waker(&self) -> &'a Waker {
&self.waker
}
}
impl fmt::Debug for Context<'_> {
fn fmt(&self, f: &mut fmt::Formatter) -> fmt::Result {
f.debug_struct("Context")
.field("waker", &self.waker)
.finish()
}
} }
/// A `Waker` is a handle for waking up a task by notifying its executor that it /// A `Waker` is a handle for waking up a task by notifying its executor that it
@ -98,6 +186,7 @@ unsafe impl Sync for Waker {}
impl Waker { impl Waker {
/// Wake up the task associated with this `Waker`. /// Wake up the task associated with this `Waker`.
#[inline]
pub fn wake(&self) { pub fn wake(&self) {
// The actual wakeup call is delegated through a virtual function call // The actual wakeup call is delegated through a virtual function call
// to the implementation which is defined by the executor. // to the implementation which is defined by the executor.
@ -115,6 +204,7 @@ impl Waker {
/// returns `true`, it is guaranteed that the `Waker`s will awaken the same task. /// returns `true`, it is guaranteed that the `Waker`s will awaken the same task.
/// ///
/// This function is primarily used for optimization purposes. /// This function is primarily used for optimization purposes.
#[inline]
pub fn will_wake(&self, other: &Waker) -> bool { pub fn will_wake(&self, other: &Waker) -> bool {
self.waker == other.waker self.waker == other.waker
} }
@ -124,6 +214,7 @@ impl Waker {
/// The behavior of the returned `Waker` is undefined if the contract defined /// The behavior of the returned `Waker` is undefined if the contract defined
/// in [`RawWaker`]'s and [`RawWakerVTable`]'s documentation is not upheld. /// in [`RawWaker`]'s and [`RawWakerVTable`]'s documentation is not upheld.
/// Therefore this method is unsafe. /// Therefore this method is unsafe.
#[inline]
pub unsafe fn new_unchecked(waker: RawWaker) -> Waker { pub unsafe fn new_unchecked(waker: RawWaker) -> Waker {
Waker { Waker {
waker, waker,
@ -132,6 +223,7 @@ impl Waker {
} }
impl Clone for Waker { impl Clone for Waker {
#[inline]
fn clone(&self) -> Self { fn clone(&self) -> Self {
Waker { Waker {
// SAFETY: This is safe because `Waker::new_unchecked` is the only way // SAFETY: This is safe because `Waker::new_unchecked` is the only way
@ -143,6 +235,7 @@ impl Clone for Waker {
} }
impl Drop for Waker { impl Drop for Waker {
#[inline]
fn drop(&mut self) { fn drop(&mut self) {
// SAFETY: This is safe because `Waker::new_unchecked` is the only way // SAFETY: This is safe because `Waker::new_unchecked` is the only way
// to initialize `drop` and `data` requiring the user to acknowledge // to initialize `drop` and `data` requiring the user to acknowledge

View File

@ -5,7 +5,7 @@ use core::marker::Unpin;
use core::pin::Pin; use core::pin::Pin;
use core::option::Option; use core::option::Option;
use core::ptr::NonNull; use core::ptr::NonNull;
use core::task::{Waker, Poll}; use core::task::{Context, Poll};
use core::ops::{Drop, Generator, GeneratorState}; use core::ops::{Drop, Generator, GeneratorState};
#[doc(inline)] #[doc(inline)]
@ -32,10 +32,10 @@ impl<T: Generator<Yield = ()>> !Unpin for GenFuture<T> {}
#[unstable(feature = "gen_future", issue = "50547")] #[unstable(feature = "gen_future", issue = "50547")]
impl<T: Generator<Yield = ()>> Future for GenFuture<T> { impl<T: Generator<Yield = ()>> Future for GenFuture<T> {
type Output = T::Return; type Output = T::Return;
fn poll(self: Pin<&mut Self>, waker: &Waker) -> Poll<Self::Output> { fn poll(self: Pin<&mut Self>, cx: &mut Context<'_>) -> Poll<Self::Output> {
// Safe because we're !Unpin + !Drop mapping to a ?Unpin value // Safe because we're !Unpin + !Drop mapping to a ?Unpin value
let gen = unsafe { Pin::map_unchecked_mut(self, |s| &mut s.0) }; let gen = unsafe { Pin::map_unchecked_mut(self, |s| &mut s.0) };
set_task_waker(waker, || match gen.resume() { set_task_context(cx, || match gen.resume() {
GeneratorState::Yielded(()) => Poll::Pending, GeneratorState::Yielded(()) => Poll::Pending,
GeneratorState::Complete(x) => Poll::Ready(x), GeneratorState::Complete(x) => Poll::Ready(x),
}) })
@ -43,61 +43,72 @@ impl<T: Generator<Yield = ()>> Future for GenFuture<T> {
} }
thread_local! { thread_local! {
static TLS_WAKER: Cell<Option<NonNull<Waker>>> = Cell::new(None); static TLS_CX: Cell<Option<NonNull<Context<'static>>>> = Cell::new(None);
} }
struct SetOnDrop(Option<NonNull<Waker>>); struct SetOnDrop(Option<NonNull<Context<'static>>>);
impl Drop for SetOnDrop { impl Drop for SetOnDrop {
fn drop(&mut self) { fn drop(&mut self) {
TLS_WAKER.with(|tls_waker| { TLS_CX.with(|tls_cx| {
tls_waker.set(self.0.take()); tls_cx.set(self.0.take());
}); });
} }
} }
#[unstable(feature = "gen_future", issue = "50547")] #[unstable(feature = "gen_future", issue = "50547")]
/// Sets the thread-local task context used by async/await futures. /// Sets the thread-local task context used by async/await futures.
pub fn set_task_waker<F, R>(waker: &Waker, f: F) -> R pub fn set_task_context<F, R>(cx: &mut Context<'_>, f: F) -> R
where where
F: FnOnce() -> R F: FnOnce() -> R
{ {
let old_waker = TLS_WAKER.with(|tls_waker| { // transmute the context's lifetime to 'static so we can store it.
tls_waker.replace(Some(NonNull::from(waker))) let cx = unsafe {
core::mem::transmute::<&mut Context<'_>, &mut Context<'static>>(cx)
};
let old_cx = TLS_CX.with(|tls_cx| {
tls_cx.replace(Some(NonNull::from(cx)))
}); });
let _reset_waker = SetOnDrop(old_waker); let _reset = SetOnDrop(old_cx);
f() f()
} }
#[unstable(feature = "gen_future", issue = "50547")] #[unstable(feature = "gen_future", issue = "50547")]
/// Retrieves the thread-local task waker used by async/await futures. /// Retrieves the thread-local task context used by async/await futures.
/// ///
/// This function acquires exclusive access to the task waker. /// This function acquires exclusive access to the task context.
/// ///
/// Panics if no waker has been set or if the waker has already been /// Panics if no context has been set or if the context has already been
/// retrieved by a surrounding call to get_task_waker. /// retrieved by a surrounding call to get_task_context.
pub fn get_task_waker<F, R>(f: F) -> R pub fn get_task_context<F, R>(f: F) -> R
where where
F: FnOnce(&Waker) -> R F: FnOnce(&mut Context<'_>) -> R
{ {
let waker_ptr = TLS_WAKER.with(|tls_waker| { let cx_ptr = TLS_CX.with(|tls_cx| {
// Clear the entry so that nested `get_task_waker` calls // Clear the entry so that nested `get_task_waker` calls
// will fail or set their own value. // will fail or set their own value.
tls_waker.replace(None) tls_cx.replace(None)
}); });
let _reset_waker = SetOnDrop(waker_ptr); let _reset = SetOnDrop(cx_ptr);
let waker_ptr = waker_ptr.expect( let mut cx_ptr = cx_ptr.expect(
"TLS Waker not set. This is a rustc bug. \ "TLS Context not set. This is a rustc bug. \
Please file an issue on https://github.com/rust-lang/rust."); Please file an issue on https://github.com/rust-lang/rust.");
unsafe { f(waker_ptr.as_ref()) }
// Safety: we've ensured exclusive access to the context by
// removing the pointer from TLS, only to be replaced once
// we're done with it.
//
// The pointer that was inserted came from an `&mut Context<'_>`,
// so it is safe to treat as mutable.
unsafe { f(cx_ptr.as_mut()) }
} }
#[unstable(feature = "gen_future", issue = "50547")] #[unstable(feature = "gen_future", issue = "50547")]
/// Polls a future in the current thread-local task waker. /// Polls a future in the current thread-local task waker.
pub fn poll_with_tls_waker<F>(f: Pin<&mut F>) -> Poll<F::Output> pub fn poll_with_tls_context<F>(f: Pin<&mut F>) -> Poll<F::Output>
where where
F: Future F: Future
{ {
get_task_waker(|waker| F::poll(f, waker)) get_task_context(|cx| F::poll(f, cx))
} }

View File

@ -346,7 +346,7 @@ macro_rules! r#await {
let mut pinned = $e; let mut pinned = $e;
loop { loop {
if let $crate::task::Poll::Ready(x) = if let $crate::task::Poll::Ready(x) =
$crate::future::poll_with_tls_waker(unsafe { $crate::future::poll_with_tls_context(unsafe {
$crate::pin::Pin::new_unchecked(&mut pinned) $crate::pin::Pin::new_unchecked(&mut pinned)
}) })
{ {

View File

@ -12,7 +12,7 @@ use crate::panicking;
use crate::ptr::{Unique, NonNull}; use crate::ptr::{Unique, NonNull};
use crate::rc::Rc; use crate::rc::Rc;
use crate::sync::{Arc, Mutex, RwLock, atomic}; use crate::sync::{Arc, Mutex, RwLock, atomic};
use crate::task::{Waker, Poll}; use crate::task::{Context, Poll};
use crate::thread::Result; use crate::thread::Result;
#[stable(feature = "panic_hooks", since = "1.10.0")] #[stable(feature = "panic_hooks", since = "1.10.0")]
@ -323,9 +323,9 @@ impl<T: fmt::Debug> fmt::Debug for AssertUnwindSafe<T> {
impl<F: Future> Future for AssertUnwindSafe<F> { impl<F: Future> Future for AssertUnwindSafe<F> {
type Output = F::Output; type Output = F::Output;
fn poll(self: Pin<&mut Self>, waker: &Waker) -> Poll<Self::Output> { fn poll(self: Pin<&mut Self>, cx: &mut Context<'_>) -> Poll<Self::Output> {
let pinned_field = unsafe { Pin::map_unchecked_mut(self, |x| &mut x.0) }; let pinned_field = unsafe { Pin::map_unchecked_mut(self, |x| &mut x.0) };
F::poll(pinned_field, waker) F::poll(pinned_field, cx)
} }
} }

View File

@ -4,7 +4,7 @@
use std::iter::Iterator; use std::iter::Iterator;
use std::future::Future; use std::future::Future;
use std::task::{Poll, Waker}; use std::task::{Context, Poll};
use std::pin::Pin; use std::pin::Pin;
use std::unimplemented; use std::unimplemented;
@ -13,7 +13,7 @@ struct MyFuture;
impl Future for MyFuture { impl Future for MyFuture {
type Output = u32; type Output = u32;
fn poll(self: Pin<&mut Self>, waker: &Waker) -> Poll<u32> { fn poll(self: Pin<&mut Self>, _: &mut Context<'_>) -> Poll<u32> {
Poll::Pending Poll::Pending
} }
} }

View File

@ -1,7 +1,7 @@
// edition:2018 // edition:2018
// aux-build:arc_wake.rs // aux-build:arc_wake.rs
#![feature(arbitrary_self_types, async_await, await_macro, futures_api)] #![feature(async_await, await_macro, futures_api)]
extern crate arc_wake; extern crate arc_wake;
@ -11,9 +11,7 @@ use std::sync::{
Arc, Arc,
atomic::{self, AtomicUsize}, atomic::{self, AtomicUsize},
}; };
use std::task::{ use std::task::{Context, Poll};
Poll, Waker,
};
use arc_wake::ArcWake; use arc_wake::ArcWake;
struct Counter { struct Counter {
@ -32,11 +30,11 @@ fn wake_and_yield_once() -> WakeOnceThenComplete { WakeOnceThenComplete(false) }
impl Future for WakeOnceThenComplete { impl Future for WakeOnceThenComplete {
type Output = (); type Output = ();
fn poll(mut self: Pin<&mut Self>, waker: &Waker) -> Poll<()> { fn poll(mut self: Pin<&mut Self>, cx: &mut Context<'_>) -> Poll<()> {
if self.0 { if self.0 {
Poll::Ready(()) Poll::Ready(())
} else { } else {
waker.wake(); cx.waker().wake();
self.0 = true; self.0 = true;
Poll::Pending Poll::Pending
} }
@ -146,10 +144,11 @@ where
let mut fut = Box::pin(f(9)); let mut fut = Box::pin(f(9));
let counter = Arc::new(Counter { wakes: AtomicUsize::new(0) }); let counter = Arc::new(Counter { wakes: AtomicUsize::new(0) });
let waker = ArcWake::into_waker(counter.clone()); let waker = ArcWake::into_waker(counter.clone());
let mut cx = Context::from_waker(&waker);
assert_eq!(0, counter.wakes.load(atomic::Ordering::SeqCst)); assert_eq!(0, counter.wakes.load(atomic::Ordering::SeqCst));
assert_eq!(Poll::Pending, fut.as_mut().poll(&waker)); assert_eq!(Poll::Pending, fut.as_mut().poll(&mut cx));
assert_eq!(1, counter.wakes.load(atomic::Ordering::SeqCst)); assert_eq!(1, counter.wakes.load(atomic::Ordering::SeqCst));
assert_eq!(Poll::Ready(9), fut.as_mut().poll(&waker)); assert_eq!(Poll::Ready(9), fut.as_mut().poll(&mut cx));
} }
fn main() { fn main() {

View File

@ -1,19 +1,19 @@
// edition:2018 // edition:2018
#![feature(arbitrary_self_types, futures_api)] #![feature(futures_api)]
use std::sync::Arc; use std::sync::Arc;
use std::task::{ use std::task::{
Poll, Waker, RawWaker, RawWakerVTable, Waker, RawWaker, RawWakerVTable,
}; };
macro_rules! waker_vtable { macro_rules! waker_vtable {
($ty:ident) => { ($ty:ident) => {
&RawWakerVTable { &RawWakerVTable::new(
clone: clone_arc_raw::<$ty>, clone_arc_raw::<$ty>,
drop: drop_arc_raw::<$ty>, wake_arc_raw::<$ty>,
wake: wake_arc_raw::<$ty>, drop_arc_raw::<$ty>,
} )
}; };
} }

View File

@ -1,7 +1,6 @@
// aux-build:arc_wake.rs // aux-build:arc_wake.rs
#![feature(arbitrary_self_types, futures_api)] #![feature(futures_api)]
#![allow(unused)]
extern crate arc_wake; extern crate arc_wake;
@ -12,7 +11,7 @@ use std::sync::{
atomic::{self, AtomicUsize}, atomic::{self, AtomicUsize},
}; };
use std::task::{ use std::task::{
Poll, Waker, Context, Poll,
}; };
use arc_wake::ArcWake; use arc_wake::ArcWake;
@ -30,8 +29,9 @@ struct MyFuture;
impl Future for MyFuture { impl Future for MyFuture {
type Output = (); type Output = ();
fn poll(self: Pin<&mut Self>, waker: &Waker) -> Poll<Self::Output> { fn poll(self: Pin<&mut Self>, cx: &mut Context<'_>) -> Poll<Self::Output> {
// Wake twice // Wake twice
let waker = cx.waker();
waker.wake(); waker.wake();
waker.wake(); waker.wake();
Poll::Ready(()) Poll::Ready(())
@ -44,10 +44,11 @@ fn test_waker() {
}); });
let waker = ArcWake::into_waker(counter.clone()); let waker = ArcWake::into_waker(counter.clone());
assert_eq!(2, Arc::strong_count(&counter)); assert_eq!(2, Arc::strong_count(&counter));
{
assert_eq!(Poll::Ready(()), Pin::new(&mut MyFuture).poll(&waker)); let mut context = Context::from_waker(&waker);
assert_eq!(2, counter.wakes.load(atomic::Ordering::SeqCst)); assert_eq!(Poll::Ready(()), Pin::new(&mut MyFuture).poll(&mut context));
assert_eq!(2, counter.wakes.load(atomic::Ordering::SeqCst));
}
drop(waker); drop(waker);
assert_eq!(1, Arc::strong_count(&counter)); assert_eq!(1, Arc::strong_count(&counter));
} }