2018-08-08 17:41:36 -07:00
|
|
|
//! Converting between JavaScript `Promise`s to Rust `Future`s.
|
2018-08-01 15:52:24 -05:00
|
|
|
//!
|
2018-08-08 17:41:36 -07:00
|
|
|
//! This crate provides a bridge for working with JavaScript `Promise` types as
|
|
|
|
//! a Rust `Future`, and similarly contains utilities to turn a rust `Future`
|
|
|
|
//! into a JavaScript `Promise`. This can be useful when working with
|
|
|
|
//! asynchronous or otherwise blocking work in Rust (wasm), and provides the
|
|
|
|
//! ability to interoperate with JavaScript events and JavaScript I/O
|
|
|
|
//! primitives.
|
2018-08-01 15:52:24 -05:00
|
|
|
//!
|
|
|
|
//! There are two main interfaces in this crate currently:
|
|
|
|
//!
|
2018-08-08 17:41:36 -07:00
|
|
|
//! 1. [**`JsFuture`**](./struct.JsFuture.html)
|
2018-08-01 15:52:24 -05:00
|
|
|
//!
|
2018-08-08 17:41:36 -07:00
|
|
|
//! A type that is constructed with a `Promise` and can then be used as a
|
|
|
|
//! `Future<Item = JsValue, Error = JsValue>`. This Rust future will resolve
|
|
|
|
//! or reject with the value coming out of the `Promise`.
|
|
|
|
//!
|
|
|
|
//! 2. [**`future_to_promise`**](./fn.future_to_promise.html)
|
|
|
|
//!
|
|
|
|
//! Converts a Rust `Future<Item = JsValue, Error = JsValue>` into a
|
|
|
|
//! JavaScript `Promise`. The future's result will translate to either a
|
|
|
|
//! rejected or resolved `Promise` in JavaScript.
|
|
|
|
//!
|
|
|
|
//! These two items should provide enough of a bridge to interoperate the two
|
|
|
|
//! systems and make sure that Rust/JavaScript can work together with
|
|
|
|
//! asynchronous and I/O work.
|
|
|
|
//!
|
|
|
|
//! # Example Usage
|
|
|
|
//!
|
|
|
|
//! This example wraps JavaScript's `Promise.resolve()` into a Rust `Future` for
|
|
|
|
//! running tasks on the next tick of the micro task queue. The futures built on
|
|
|
|
//! top of it can be scheduled for execution by conversion into a JavaScript
|
|
|
|
//! `Promise`.
|
|
|
|
//!
|
|
|
|
//! ```rust,no_run
|
|
|
|
//! extern crate futures;
|
|
|
|
//! extern crate js_sys;
|
|
|
|
//! extern crate wasm_bindgen;
|
|
|
|
//! extern crate wasm_bindgen_futures;
|
|
|
|
//!
|
|
|
|
//! use futures::{Async, Future, Poll};
|
|
|
|
//! use wasm_bindgen::prelude::*;
|
|
|
|
//! use wasm_bindgen_futures::{JsFuture, future_to_promise};
|
|
|
|
//!
|
|
|
|
//! /// A future that becomes ready after a tick of the micro task queue.
|
|
|
|
//! pub struct NextTick {
|
|
|
|
//! inner: JsFuture,
|
|
|
|
//! }
|
|
|
|
//!
|
|
|
|
//! impl NextTick {
|
|
|
|
//! /// Construct a new `NextTick` future.
|
|
|
|
//! pub fn new() -> NextTick {
|
|
|
|
//! // Create a resolved promise that will run its callbacks on the next
|
|
|
|
//! // tick of the micro task queue.
|
2018-08-09 13:08:30 -07:00
|
|
|
//! let promise = js_sys::Promise::resolve(&JsValue::NULL);
|
2018-08-08 17:41:36 -07:00
|
|
|
//! // Convert the promise into a `JsFuture`.
|
|
|
|
//! let inner = JsFuture::from(promise);
|
|
|
|
//! NextTick { inner }
|
|
|
|
//! }
|
|
|
|
//! }
|
|
|
|
//!
|
|
|
|
//! impl Future for NextTick {
|
|
|
|
//! type Item = ();
|
|
|
|
//! type Error = ();
|
|
|
|
//!
|
|
|
|
//! fn poll(&mut self) -> Poll<(), ()> {
|
|
|
|
//! // Polling a `NextTick` just forwards to polling if the inner promise is
|
|
|
|
//! // ready.
|
|
|
|
//! match self.inner.poll() {
|
|
|
|
//! Ok(Async::Ready(_)) => Ok(Async::Ready(())),
|
|
|
|
//! Ok(Async::NotReady) => Ok(Async::NotReady),
|
|
|
|
//! Err(_) => unreachable!(
|
|
|
|
//! "We only create NextTick with a resolved inner promise, never \
|
|
|
|
//! a rejected one, so we can't get an error here"
|
|
|
|
//! ),
|
|
|
|
//! }
|
|
|
|
//! }
|
|
|
|
//! }
|
|
|
|
//!
|
|
|
|
//! /// Export a function to JavaScript that does some work in the next tick of the
|
|
|
|
//! /// micro task queue!
|
|
|
|
//! #[wasm_bindgen]
|
|
|
|
//! pub fn schedule_some_work_for_next_tick() -> js_sys::Promise {
|
|
|
|
//! let future = NextTick::new()
|
|
|
|
//! // Do some work...
|
|
|
|
//! .and_then(|_| {
|
|
|
|
//! Ok(42)
|
|
|
|
//! })
|
|
|
|
//! // And then convert the `Item` and `Error` into `JsValue`.
|
|
|
|
//! .map(|result| {
|
|
|
|
//! JsValue::from(result)
|
|
|
|
//! })
|
|
|
|
//! .map_err(|error| {
|
|
|
|
//! let js_error = js_sys::Error::new(&format!("uh oh! {:?}", error));
|
|
|
|
//! JsValue::from(js_error)
|
|
|
|
//! });
|
|
|
|
//!
|
|
|
|
//! // Convert the `Future<Item = JsValue, Error = JsValue>` into a JavaScript
|
|
|
|
//! // `Promise`!
|
|
|
|
//! future_to_promise(future)
|
|
|
|
//! }
|
|
|
|
//! ```
|
2018-08-01 15:52:24 -05:00
|
|
|
|
|
|
|
#![deny(missing_docs)]
|
|
|
|
|
2019-05-04 09:17:29 +02:00
|
|
|
#[cfg(feature = "futures_0_3")]
|
|
|
|
/// Contains a Futures 0.3 implementation of this crate.
|
|
|
|
pub mod futures_0_3;
|
2018-08-01 15:52:24 -05:00
|
|
|
|
2019-05-04 09:17:29 +02:00
|
|
|
use std::cell::{Cell, RefCell};
|
|
|
|
use std::fmt;
|
|
|
|
use std::rc::Rc;
|
2019-06-10 21:10:06 +03:00
|
|
|
#[cfg(target_feature = "atomics")]
|
2019-05-19 22:04:17 +03:00
|
|
|
use std::sync::atomic::{AtomicBool, Ordering};
|
2019-05-04 09:17:29 +02:00
|
|
|
use std::sync::Arc;
|
2019-06-10 21:10:06 +03:00
|
|
|
#[cfg(target_feature = "atomics")]
|
|
|
|
use std::sync::Mutex;
|
2018-08-01 15:52:24 -05:00
|
|
|
|
2019-05-04 09:17:29 +02:00
|
|
|
use futures::executor::{self, Notify, Spawn};
|
|
|
|
use futures::future;
|
|
|
|
use futures::prelude::*;
|
|
|
|
use futures::sync::oneshot;
|
2019-06-10 21:10:06 +03:00
|
|
|
use js_sys::{Function, Promise};
|
|
|
|
#[cfg(target_feature = "atomics")]
|
|
|
|
use js_sys::{Atomics, Int32Array, SharedArrayBuffer, WebAssembly};
|
2019-05-04 09:17:29 +02:00
|
|
|
use wasm_bindgen::prelude::*;
|
2019-06-10 21:10:06 +03:00
|
|
|
#[cfg(target_feature = "atomics")]
|
|
|
|
use wasm_bindgen::JsCast;
|
2018-08-01 15:52:24 -05:00
|
|
|
|
2019-06-10 21:10:06 +03:00
|
|
|
#[cfg(target_feature = "atomics")]
|
2019-05-19 22:04:17 +03:00
|
|
|
mod polyfill;
|
|
|
|
|
2019-06-10 21:10:06 +03:00
|
|
|
macro_rules! console_log {
|
|
|
|
($($t:tt)*) => (log(&format_args!($($t)*).to_string()))
|
|
|
|
}
|
|
|
|
|
|
|
|
#[wasm_bindgen]
|
|
|
|
extern "C" {
|
|
|
|
#[wasm_bindgen(js_namespace = console)]
|
|
|
|
fn log(s: &str);
|
|
|
|
}
|
|
|
|
|
2019-05-04 09:17:29 +02:00
|
|
|
/// A Rust `Future` backed by a JavaScript `Promise`.
|
|
|
|
///
|
|
|
|
/// This type is constructed with a JavaScript `Promise` object and translates
|
|
|
|
/// it to a Rust `Future`. This type implements the `Future` trait from the
|
|
|
|
/// `futures` crate and will either succeed or fail depending on what happens
|
|
|
|
/// with the JavaScript `Promise`.
|
|
|
|
///
|
|
|
|
/// Currently this type is constructed with `JsFuture::from`.
|
|
|
|
pub struct JsFuture {
|
2019-07-08 09:32:25 -07:00
|
|
|
rx: oneshot::Receiver<Result<JsValue, JsValue>>,
|
2019-05-04 09:17:29 +02:00
|
|
|
}
|
|
|
|
|
|
|
|
impl fmt::Debug for JsFuture {
|
|
|
|
fn fmt(&self, f: &mut fmt::Formatter) -> fmt::Result {
|
|
|
|
write!(f, "JsFuture {{ ... }}")
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
impl From<Promise> for JsFuture {
|
|
|
|
fn from(js: Promise) -> JsFuture {
|
|
|
|
// Use the `then` method to schedule two callbacks, one for the
|
2019-07-08 09:32:25 -07:00
|
|
|
// resolved value and one for the rejected value. We're currently
|
|
|
|
// assuming that JS engines will unconditionally invoke precisely one of
|
|
|
|
// these callbacks, no matter what.
|
2019-05-04 09:17:29 +02:00
|
|
|
//
|
2019-07-08 09:32:25 -07:00
|
|
|
// Ideally we'd have a way to cancel the callbacks getting invoked and
|
|
|
|
// free up state ourselves when this `JsFuture` is dropped. We don't
|
|
|
|
// have that, though, and one of the callbacks is likely always going to
|
|
|
|
// be invoked.
|
|
|
|
//
|
|
|
|
// As a result we need to make sure that no matter when the callbacks
|
|
|
|
// are invoked they are valid to be called at any time, which means they
|
|
|
|
// have to be self-contained. Through the `Closure::once` and some
|
|
|
|
// `Rc`-trickery we can arrange for both instances of `Closure`, and the
|
|
|
|
// `Rc`, to all be destroyed once the first one is called.
|
|
|
|
let (tx, rx) = oneshot::channel();
|
|
|
|
let state = Rc::new(RefCell::new(None));
|
|
|
|
let state2 = state.clone();
|
|
|
|
let resolve = Closure::once(move |val| finish(&state2, Ok(val)));
|
|
|
|
let state2 = state.clone();
|
|
|
|
let reject = Closure::once(move |val| finish(&state2, Err(val)));
|
2019-05-04 09:17:29 +02:00
|
|
|
|
|
|
|
js.then2(&resolve, &reject);
|
2019-07-08 09:32:25 -07:00
|
|
|
*state.borrow_mut() = Some((tx, resolve, reject));
|
|
|
|
|
|
|
|
return JsFuture { rx };
|
2019-05-04 09:17:29 +02:00
|
|
|
|
2019-07-08 09:32:25 -07:00
|
|
|
fn finish(
|
|
|
|
state: &RefCell<
|
|
|
|
Option<(
|
|
|
|
oneshot::Sender<Result<JsValue, JsValue>>,
|
|
|
|
Closure<dyn FnMut(JsValue)>,
|
|
|
|
Closure<dyn FnMut(JsValue)>,
|
|
|
|
)>,
|
|
|
|
>,
|
|
|
|
val: Result<JsValue, JsValue>,
|
|
|
|
) {
|
|
|
|
match state.borrow_mut().take() {
|
|
|
|
// We don't have any guarantee that anyone's still listening at this
|
|
|
|
// point (the Rust `JsFuture` could have been dropped) so simply
|
|
|
|
// ignore any errors here.
|
|
|
|
Some((tx, _, _)) => drop(tx.send(val)),
|
|
|
|
None => wasm_bindgen::throw_str("cannot finish twice"),
|
|
|
|
}
|
2019-05-04 09:17:29 +02:00
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
impl Future for JsFuture {
|
|
|
|
type Item = JsValue;
|
|
|
|
type Error = JsValue;
|
|
|
|
|
|
|
|
fn poll(&mut self) -> Poll<JsValue, JsValue> {
|
2019-07-08 09:32:25 -07:00
|
|
|
match self.rx.poll() {
|
|
|
|
Ok(Async::Ready(val)) => val.map(Async::Ready),
|
|
|
|
Ok(Async::NotReady) => Ok(Async::NotReady),
|
|
|
|
Err(_) => wasm_bindgen::throw_str("cannot cancel"),
|
2019-05-04 09:17:29 +02:00
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
/// Converts a Rust `Future` into a JavaScript `Promise`.
|
|
|
|
///
|
|
|
|
/// This function will take any future in Rust and schedule it to be executed,
|
|
|
|
/// returning a JavaScript `Promise` which can then be passed back to JavaScript
|
|
|
|
/// to get plumbed into the rest of a system.
|
|
|
|
///
|
|
|
|
/// The `future` provided must adhere to `'static` because it'll be scheduled
|
|
|
|
/// to run in the background and cannot contain any stack references. The
|
|
|
|
/// returned `Promise` will be resolved or rejected when the future completes,
|
|
|
|
/// depending on whether it finishes with `Ok` or `Err`.
|
|
|
|
///
|
|
|
|
/// # Panics
|
|
|
|
///
|
|
|
|
/// Note that in wasm panics are currently translated to aborts, but "abort" in
|
|
|
|
/// this case means that a JavaScript exception is thrown. The wasm module is
|
|
|
|
/// still usable (likely erroneously) after Rust panics.
|
|
|
|
///
|
|
|
|
/// If the `future` provided panics then the returned `Promise` **will not
|
|
|
|
/// resolve**. Instead it will be a leaked promise. This is an unfortunate
|
|
|
|
/// limitation of wasm currently that's hoped to be fixed one day!
|
|
|
|
pub fn future_to_promise<F>(future: F) -> Promise
|
|
|
|
where
|
|
|
|
F: Future<Item = JsValue, Error = JsValue> + 'static,
|
|
|
|
{
|
|
|
|
_future_to_promise(Box::new(future))
|
|
|
|
}
|
|
|
|
|
|
|
|
// Implementation of actually transforming a future into a JavaScript `Promise`.
|
|
|
|
//
|
|
|
|
// The only primitive we have to work with here is `Promise::new`, which gives
|
|
|
|
// us two callbacks that we can use to either reject or resolve the promise.
|
|
|
|
// It's our job to ensure that one of those callbacks is called at the
|
|
|
|
// appropriate time.
|
|
|
|
//
|
|
|
|
// Now we know that JavaScript (in general) can't block and is largely
|
|
|
|
// notification/callback driven. That means that our future must either have
|
|
|
|
// synchronous computational work to do, or it's "scheduled a notification" to
|
|
|
|
// happen. These notifications are likely callbacks to get executed when things
|
|
|
|
// finish (like a different promise or something like `setTimeout`). The general
|
|
|
|
// idea here is thus to do as much synchronous work as we can and then otherwise
|
|
|
|
// translate notifications of a future's task into "let's poll the future!"
|
|
|
|
//
|
|
|
|
// This isn't necessarily the greatest future executor in the world, but it
|
|
|
|
// should get the job done for now hopefully.
|
2019-06-03 08:26:14 -07:00
|
|
|
fn _future_to_promise(future: Box<dyn Future<Item = JsValue, Error = JsValue>>) -> Promise {
|
2019-05-04 09:17:29 +02:00
|
|
|
let mut future = Some(executor::spawn(future));
|
|
|
|
return Promise::new(&mut |resolve, reject| {
|
|
|
|
Package::poll(&Arc::new(Package {
|
|
|
|
spawn: RefCell::new(future.take().unwrap()),
|
|
|
|
resolve,
|
|
|
|
reject,
|
|
|
|
notified: Cell::new(State::Notified),
|
2019-06-10 21:10:06 +03:00
|
|
|
#[cfg(target_feature = "atomics")]
|
|
|
|
waker: Arc::new(Waker::new(vec![0; 4], false)),
|
2019-05-04 09:17:29 +02:00
|
|
|
}));
|
|
|
|
});
|
|
|
|
|
|
|
|
struct Package {
|
|
|
|
// Our "spawned future". This'll have everything we need to poll the
|
|
|
|
// future and continue to move it forward.
|
2019-06-03 08:26:14 -07:00
|
|
|
spawn: RefCell<Spawn<Box<dyn Future<Item = JsValue, Error = JsValue>>>>,
|
2019-05-04 09:17:29 +02:00
|
|
|
|
|
|
|
// The current state of this future, expressed in an enum below. This
|
|
|
|
// indicates whether we're currently polling the future, received a
|
|
|
|
// notification and need to keep polling, or if we're waiting for a
|
|
|
|
// notification to come in (and no one is polling).
|
|
|
|
notified: Cell<State>,
|
|
|
|
|
|
|
|
// Our two callbacks connected to the `Promise` that we returned to
|
|
|
|
// JavaScript. We'll be invoking one of these at the end.
|
|
|
|
resolve: Function,
|
|
|
|
reject: Function,
|
2019-05-19 22:04:17 +03:00
|
|
|
|
2019-06-10 21:10:06 +03:00
|
|
|
#[cfg(target_feature = "atomics")]
|
2019-05-19 22:04:17 +03:00
|
|
|
// Struct to wake a future
|
|
|
|
waker: Arc<Waker>,
|
2019-05-04 09:17:29 +02:00
|
|
|
}
|
|
|
|
|
|
|
|
// The possible states our `Package` (future) can be in, tracked internally
|
|
|
|
// and used to guide what happens when polling a future.
|
|
|
|
enum State {
|
|
|
|
// This future is currently and actively being polled. Attempting to
|
|
|
|
// access the future will result in a runtime panic and is considered a
|
|
|
|
// bug.
|
|
|
|
Polling,
|
|
|
|
|
|
|
|
// This future has been notified, while it was being polled. This marker
|
|
|
|
// is used in the `Notify` implementation below, and indicates that a
|
|
|
|
// notification was received that the future is ready to make progress.
|
|
|
|
// If seen, however, it probably means that the future is also currently
|
|
|
|
// being polled.
|
|
|
|
Notified,
|
|
|
|
|
|
|
|
// The future is blocked, waiting for something to happen. Stored here
|
|
|
|
// is a self-reference to the future itself so we can pull it out in
|
|
|
|
// `Notify` and continue polling.
|
|
|
|
//
|
|
|
|
// Note that the self-reference here is an Arc-cycle that will leak
|
|
|
|
// memory unless the future completes, but currently that should be ok
|
|
|
|
// as we'll have to stick around anyway while the future is executing!
|
|
|
|
//
|
|
|
|
// This state is removed as soon as a notification comes in, so the leak
|
|
|
|
// should only be "temporary"
|
|
|
|
Waiting(Arc<Package>),
|
|
|
|
}
|
|
|
|
|
2019-06-10 21:10:06 +03:00
|
|
|
#[cfg(target_feature = "atomics")]
|
2019-05-19 22:04:17 +03:00
|
|
|
struct Waker {
|
2019-06-10 21:10:06 +03:00
|
|
|
array: Vec<i32>,
|
2019-05-19 22:04:17 +03:00
|
|
|
notified: AtomicBool,
|
|
|
|
};
|
|
|
|
|
2019-06-10 21:10:06 +03:00
|
|
|
#[cfg(target_feature = "atomics")]
|
2019-05-19 22:04:17 +03:00
|
|
|
impl Waker {
|
2019-06-10 21:10:06 +03:00
|
|
|
fn new(array: Vec<i32>, notified: bool) -> Self {
|
|
|
|
Waker {
|
|
|
|
array,
|
2019-05-19 22:04:17 +03:00
|
|
|
notified: AtomicBool::new(notified),
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2019-06-10 21:10:06 +03:00
|
|
|
#[cfg(target_feature = "atomics")]
|
2019-05-19 22:04:17 +03:00
|
|
|
impl Notify for Waker {
|
|
|
|
fn notify(&self, id: usize) {
|
2019-06-10 21:10:06 +03:00
|
|
|
console_log!("Waker notify");
|
2019-05-19 22:04:17 +03:00
|
|
|
if !self.notified.swap(true, Ordering::SeqCst) {
|
2019-06-10 21:10:06 +03:00
|
|
|
console_log!("Waker, inside if");
|
|
|
|
let memory_buffer = wasm_bindgen::memory()
|
|
|
|
.dyn_into::<WebAssembly::Memory>()
|
|
|
|
.expect("Should cast a memory to WebAssembly::Memory")
|
|
|
|
.buffer();
|
|
|
|
|
|
|
|
let array_location = self.array.as_ptr() as u32 / 4;
|
|
|
|
let array = Int32Array::new(&memory_buffer)
|
|
|
|
.subarray(array_location, array_location + self.array.len() as u32);
|
|
|
|
|
2019-05-19 22:04:17 +03:00
|
|
|
let _ = Atomics::notify(&array, id as u32);
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2019-06-10 21:10:06 +03:00
|
|
|
#[cfg(target_feature = "atomics")]
|
2019-05-19 22:04:17 +03:00
|
|
|
fn poll_again(package: Arc<Package>, id: usize) {
|
2019-06-10 21:10:06 +03:00
|
|
|
console_log!("poll_again called");
|
2019-05-19 22:04:17 +03:00
|
|
|
let me = match package.notified.replace(State::Notified) {
|
|
|
|
// we need to schedule polling to resume, so keep going
|
2019-06-10 21:10:06 +03:00
|
|
|
State::Waiting(me) => {
|
|
|
|
console_log!("poll_again Waiting");
|
|
|
|
me
|
|
|
|
},
|
2019-05-19 22:04:17 +03:00
|
|
|
|
|
|
|
// we were already notified, and were just notified again;
|
|
|
|
// having now coalesced the notifications we return as it's
|
|
|
|
// still someone else's job to process this
|
2019-06-10 21:10:06 +03:00
|
|
|
State::Notified => {
|
|
|
|
console_log!("poll_again Notified");
|
|
|
|
return;
|
|
|
|
},
|
2019-05-19 22:04:17 +03:00
|
|
|
|
|
|
|
// the future was previously being polled, and we've just
|
|
|
|
// switched it to the "you're notified" state. We don't have
|
|
|
|
// access to the future as it's being polled, so the future
|
|
|
|
// polling process later sees this notification and will
|
|
|
|
// continue polling. For us, though, there's nothing else to do,
|
|
|
|
// so we bail out.
|
|
|
|
// later see
|
2019-06-10 21:10:06 +03:00
|
|
|
State::Polling => {
|
|
|
|
console_log!("poll_again Polling");
|
|
|
|
return;
|
|
|
|
},
|
2019-05-19 22:04:17 +03:00
|
|
|
};
|
|
|
|
|
2019-06-10 21:10:06 +03:00
|
|
|
let memory_buffer = wasm_bindgen::memory()
|
|
|
|
.dyn_into::<WebAssembly::Memory>()
|
|
|
|
.expect("Should cast a memory to WebAssembly::Memory")
|
|
|
|
.buffer();
|
|
|
|
|
|
|
|
let array_location = package.waker.array.as_ptr() as u32 / 4;
|
|
|
|
let array = Int32Array::new(&memory_buffer)
|
|
|
|
.subarray(array_location, array_location + package.waker.array.len() as u32);
|
|
|
|
|
2019-05-19 22:04:17 +03:00
|
|
|
// Use `Promise.then` on a resolved promise to place our execution
|
|
|
|
// onto the next turn of the microtask queue, enqueueing our poll
|
|
|
|
// operation. We don't currently poll immediately as it turns out
|
|
|
|
// `futures` crate adapters aren't compatible with it and it also
|
|
|
|
// helps avoid blowing the stack by accident.
|
|
|
|
//
|
|
|
|
// Note that the `Rc`/`RefCell` trick here is basically to just
|
|
|
|
// ensure that our `Closure` gets cleaned up appropriately.
|
2019-06-10 21:10:06 +03:00
|
|
|
let promise = polyfill::wait_async(array, id as u32, 0)
|
2019-05-29 22:36:57 +03:00
|
|
|
.expect("Should create a Promise");
|
2019-05-19 22:04:17 +03:00
|
|
|
let slot = Rc::new(RefCell::new(None));
|
|
|
|
let slot2 = slot.clone();
|
|
|
|
let closure = Closure::wrap(Box::new(move |_| {
|
|
|
|
let myself = slot2.borrow_mut().take();
|
|
|
|
debug_assert!(myself.is_some());
|
|
|
|
Package::poll(&me);
|
2019-06-10 21:10:06 +03:00
|
|
|
}) as Box<dyn FnMut(JsValue)>);
|
2019-05-19 22:04:17 +03:00
|
|
|
promise.then(&closure);
|
|
|
|
*slot.borrow_mut() = Some(closure);
|
|
|
|
}
|
2019-05-04 09:17:29 +02:00
|
|
|
|
2019-06-10 21:10:06 +03:00
|
|
|
// No shared memory right now, wasm is single threaded, no need to worry
|
|
|
|
// about this!
|
|
|
|
#[cfg(not(target_feature = "atomics"))]
|
|
|
|
unsafe impl Send for Package {}
|
|
|
|
#[cfg(not(target_feature = "atomics"))]
|
|
|
|
unsafe impl Sync for Package {}
|
|
|
|
|
2019-05-04 09:17:29 +02:00
|
|
|
impl Package {
|
|
|
|
// Move the future contained in `me` as far forward as we can. This will
|
|
|
|
// do as much synchronous work as possible to complete the future,
|
|
|
|
// ensuring that when it blocks we're scheduled to get notified via some
|
|
|
|
// callback somewhere at some point (vague, right?)
|
|
|
|
//
|
|
|
|
// TODO: this probably shouldn't do as much synchronous work as possible
|
|
|
|
// as it can starve other computations. Rather it should instead
|
|
|
|
// yield every so often with something like `setTimeout` with the
|
|
|
|
// timeout set to zero.
|
|
|
|
fn poll(me: &Arc<Package>) {
|
|
|
|
loop {
|
|
|
|
match me.notified.replace(State::Polling) {
|
|
|
|
// We received a notification while previously polling, or
|
|
|
|
// this is the initial poll. We've got work to do below!
|
2019-06-10 21:10:06 +03:00
|
|
|
State::Notified => {
|
|
|
|
console_log!("Package::poll Notified");
|
|
|
|
}
|
2019-05-04 09:17:29 +02:00
|
|
|
|
|
|
|
// We've gone through this loop once and no notification was
|
|
|
|
// received while we were executing work. That means we got
|
|
|
|
// `NotReady` below and we're scheduled to receive a
|
|
|
|
// notification. Block ourselves and wait for later.
|
|
|
|
//
|
|
|
|
// When the notification comes in it'll notify our task, see
|
|
|
|
// our `Waiting` state, and resume the polling process
|
|
|
|
State::Polling => {
|
2019-06-10 21:10:06 +03:00
|
|
|
console_log!("Package::poll Polling");
|
|
|
|
|
2019-05-04 09:17:29 +02:00
|
|
|
me.notified.set(State::Waiting(me.clone()));
|
2019-06-10 21:10:06 +03:00
|
|
|
|
|
|
|
#[cfg(target_feature = "atomics")]
|
2019-05-19 22:04:17 +03:00
|
|
|
poll_again(me.clone(), 0);
|
2019-06-10 21:10:06 +03:00
|
|
|
|
2019-05-04 09:17:29 +02:00
|
|
|
break;
|
|
|
|
}
|
|
|
|
|
2019-06-10 21:10:06 +03:00
|
|
|
State::Waiting(_) => {
|
|
|
|
console_log!("Package::poll Waiting");
|
|
|
|
|
|
|
|
panic!("shouldn't see waiting state!")
|
|
|
|
},
|
2019-05-04 09:17:29 +02:00
|
|
|
}
|
|
|
|
|
2019-06-10 21:10:06 +03:00
|
|
|
|
|
|
|
#[cfg(target_feature = "atomics")]
|
|
|
|
let waker = &me.waker;
|
|
|
|
|
|
|
|
#[cfg(not(target_feature = "atomics"))]
|
|
|
|
let waker = me;
|
|
|
|
|
|
|
|
let (val, f) = match me.spawn.borrow_mut().poll_future_notify(waker, 0) {
|
2019-05-04 09:17:29 +02:00
|
|
|
// If the future is ready, immediately call the
|
|
|
|
// resolve/reject callback and then return as we're done.
|
|
|
|
Ok(Async::Ready(value)) => (value, &me.resolve),
|
|
|
|
Err(value) => (value, &me.reject),
|
|
|
|
|
|
|
|
// Otherwise keep going in our loop, if we weren't notified
|
|
|
|
// we'll break out and start waiting.
|
|
|
|
Ok(Async::NotReady) => continue,
|
|
|
|
};
|
|
|
|
|
|
|
|
drop(f.call1(&JsValue::undefined(), &val));
|
|
|
|
break;
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
2019-06-10 21:10:06 +03:00
|
|
|
|
|
|
|
#[cfg(not(target_feature = "atomics"))]
|
|
|
|
impl Notify for Package {
|
|
|
|
fn notify(&self, _id: usize) {
|
|
|
|
console_log!("Package::notify Waiting");
|
|
|
|
let me = match self.notified.replace(State::Notified) {
|
|
|
|
// we need to schedule polling to resume, so keep going
|
|
|
|
State::Waiting(me) => me,
|
|
|
|
|
|
|
|
// we were already notified, and were just notified again;
|
|
|
|
// having now coalesced the notifications we return as it's
|
|
|
|
// still someone else's job to process this
|
|
|
|
State::Notified => return,
|
|
|
|
|
|
|
|
// the future was previously being polled, and we've just
|
|
|
|
// switched it to the "you're notified" state. We don't have
|
|
|
|
// access to the future as it's being polled, so the future
|
|
|
|
// polling process later sees this notification and will
|
|
|
|
// continue polling. For us, though, there's nothing else to do,
|
|
|
|
// so we bail out.
|
|
|
|
// later see
|
|
|
|
State::Polling => return,
|
|
|
|
};
|
|
|
|
|
|
|
|
// Use `Promise.then` on a resolved promise to place our execution
|
|
|
|
// onto the next turn of the microtask queue, enqueueing our poll
|
|
|
|
// operation. We don't currently poll immediately as it turns out
|
|
|
|
// `futures` crate adapters aren't compatible with it and it also
|
|
|
|
// helps avoid blowing the stack by accident.
|
|
|
|
//
|
|
|
|
// Note that the `Rc`/`RefCell` trick here is basically to just
|
|
|
|
// ensure that our `Closure` gets cleaned up appropriately.
|
|
|
|
let promise = Promise::resolve(&JsValue::undefined());
|
|
|
|
let slot = Rc::new(RefCell::new(None));
|
|
|
|
let slot2 = slot.clone();
|
|
|
|
let closure = Closure::wrap(Box::new(move |_| {
|
|
|
|
let myself = slot2.borrow_mut().take();
|
|
|
|
debug_assert!(myself.is_some());
|
|
|
|
Package::poll(&me);
|
|
|
|
}) as Box<dyn FnMut(JsValue)>);
|
|
|
|
promise.then(&closure);
|
|
|
|
*slot.borrow_mut() = Some(closure);
|
|
|
|
}
|
|
|
|
}
|
2019-05-04 09:17:29 +02:00
|
|
|
}
|
|
|
|
|
|
|
|
/// Converts a Rust `Future` on a local task queue.
|
|
|
|
///
|
|
|
|
/// The `future` provided must adhere to `'static` because it'll be scheduled
|
|
|
|
/// to run in the background and cannot contain any stack references.
|
|
|
|
///
|
|
|
|
/// # Panics
|
|
|
|
///
|
|
|
|
/// This function has the same panic behavior as `future_to_promise`.
|
|
|
|
pub fn spawn_local<F>(future: F)
|
|
|
|
where
|
|
|
|
F: Future<Item = (), Error = ()> + 'static,
|
|
|
|
{
|
|
|
|
future_to_promise(
|
|
|
|
future
|
|
|
|
.map(|()| JsValue::undefined())
|
|
|
|
.or_else(|()| future::ok::<JsValue, JsValue>(JsValue::undefined())),
|
|
|
|
);
|
|
|
|
}
|