jsonrpc_pubsub/oneshot.rs
1 2 3 4 5 6 7 8 9 10 11 12 13 14 15 16 17 18 19 20 21 22 23 24 25 26 27 28 29 30 31 32 33 34 35 36 37 38 39 40 41 42 43 44 45 46 47 48 49 50 51 52 53 54 55 56 57 58 59 60 61 62 63 64 65 66 67 68 69 70 71 72 73 74 75 76 77 78 79 80 81 82 83 84 85 86 87 88 89 90 91 92 93 94 95 96 97 98 99 100
//! A futures oneshot channel that can be used for rendezvous.
use crate::core::futures::{self, channel::oneshot, future, Future, FutureExt, TryFutureExt};
use std::ops::{Deref, DerefMut};
/// Create a new future-base rendezvous channel.
///
/// The returned `Sender` and `Receiver` objects are wrapping
/// the regular `futures::channel::oneshot` counterparts and have the same functionality.
/// Additionaly `Sender::send_and_wait` allows you to send a message to the channel
/// and get a future that resolves when the message is consumed.
pub fn channel<T>() -> (Sender<T>, Receiver<T>) {
let (sender, receiver) = oneshot::channel();
let (receipt_tx, receipt_rx) = oneshot::channel();
(
Sender {
sender,
receipt: receipt_rx,
},
Receiver {
receiver,
receipt: Some(receipt_tx),
},
)
}
/// A sender part of the channel.
#[derive(Debug)]
pub struct Sender<T> {
sender: oneshot::Sender<T>,
receipt: oneshot::Receiver<()>,
}
impl<T> Sender<T> {
/// Consume the sender and queue up an item to send.
///
/// This method returns right away and never blocks,
/// there is no guarantee though that the message is received
/// by the other end.
pub fn send(self, t: T) -> Result<(), T> {
self.sender.send(t)
}
/// Consume the sender and send an item.
///
/// The returned future will resolve when the message is received
/// on the other end. Note that polling the future is actually not required
/// to send the message as that happens synchronously.
/// The future resolves to error in case the receiving end was dropped before
/// being able to process the message.
pub fn send_and_wait(self, t: T) -> impl Future<Output = Result<(), ()>> {
let Self { sender, receipt } = self;
if sender.send(t).is_err() {
return future::Either::Left(future::ready(Err(())));
}
future::Either::Right(receipt.map_err(|_| ()))
}
}
impl<T> Deref for Sender<T> {
type Target = oneshot::Sender<T>;
fn deref(&self) -> &Self::Target {
&self.sender
}
}
impl<T> DerefMut for Sender<T> {
fn deref_mut(&mut self) -> &mut Self::Target {
&mut self.sender
}
}
/// Receiving end of the channel.
///
/// When this object is `polled` and the result is `Ready`
/// the other end (`Sender`) is also notified about the fact
/// that the item has been consumed and the future returned
/// by `send_and_wait` resolves.
#[must_use = "futures do nothing unless polled"]
#[derive(Debug)]
pub struct Receiver<T> {
receiver: oneshot::Receiver<T>,
receipt: Option<oneshot::Sender<()>>,
}
impl<T> Future for Receiver<T> {
type Output = <oneshot::Receiver<T> as Future>::Output;
fn poll(mut self: std::pin::Pin<&mut Self>, cx: &mut futures::task::Context) -> futures::task::Poll<Self::Output> {
let r = futures::ready!(self.receiver.poll_unpin(cx))?;
if let Some(receipt) = self.receipt.take() {
let _ = receipt.send(());
}
Ok(r).into()
}
}