remove async
This commit is contained in:
parent
6569977549
commit
e645e3bf0c
|
@ -7,7 +7,7 @@ use std::{
|
||||||
|
|
||||||
use futures::{
|
use futures::{
|
||||||
future::{FutureExt, TryFutureExt},
|
future::{FutureExt, TryFutureExt},
|
||||||
stream::TryStreamExt,
|
stream::{Stream, TryStreamExt},
|
||||||
};
|
};
|
||||||
use tokio::sync::oneshot;
|
use tokio::sync::oneshot;
|
||||||
use tower::{buffer::Buffer, util::BoxService, Service, ServiceExt};
|
use tower::{buffer::Buffer, util::BoxService, Service, ServiceExt};
|
||||||
|
|
|
@ -79,11 +79,11 @@ where
|
||||||
|
|
||||||
impl<ZN, ZV, ZS> Downloads<ZN, ZV, ZS>
|
impl<ZN, ZV, ZS> Downloads<ZN, ZV, ZS>
|
||||||
where
|
where
|
||||||
ZN: Service<zn::Request, Response = zn::Response, Error = BoxError> + Send + 'static,
|
ZN: Service<zn::Request, Response = zn::Response, Error = BoxError> + Send + Clone + 'static,
|
||||||
ZN::Future: Send,
|
ZN::Future: Send,
|
||||||
ZV: Service<Arc<Block>, Response = block::Hash, Error = BoxError> + Send + Clone + 'static,
|
ZV: Service<Arc<Block>, Response = block::Hash, Error = BoxError> + Send + Clone + 'static,
|
||||||
ZV::Future: Send,
|
ZV::Future: Send,
|
||||||
ZS: Service<zs::Request, Response = zs::Response, Error = BoxError> + Send + 'static,
|
ZS: Service<zs::Request, Response = zs::Response, Error = BoxError> + Send + Clone + 'static,
|
||||||
ZS::Future: Send,
|
ZS::Future: Send,
|
||||||
{
|
{
|
||||||
/// Initialize a new download stream with the provided `network` and
|
/// Initialize a new download stream with the provided `network` and
|
||||||
|
@ -104,95 +104,61 @@ where
|
||||||
|
|
||||||
/// Queue a block for download and verification.
|
/// Queue a block for download and verification.
|
||||||
///
|
///
|
||||||
/// This method waits for the network to become ready, and returns an error
|
/// Returns true if the block was newly queued, and false if it was already queued.
|
||||||
/// only if the network service fails. It returns immediately after queuing
|
|
||||||
/// the request.
|
|
||||||
#[instrument(skip(self))]
|
#[instrument(skip(self))]
|
||||||
pub async fn download_and_verify(&mut self, hash: block::Hash) -> Result<bool, Report> {
|
pub fn download_and_verify(&mut self, hash: block::Hash) -> bool {
|
||||||
if self.cancel_handles.contains_key(&hash) {
|
if self.cancel_handles.contains_key(&hash) {
|
||||||
return Ok(false);
|
return false;
|
||||||
}
|
}
|
||||||
|
|
||||||
// Check if the block is already in the state.
|
|
||||||
let block_state_req = self
|
|
||||||
.state
|
|
||||||
.ready_and()
|
|
||||||
.await
|
|
||||||
.map_err(|e| eyre!(e))?
|
|
||||||
.call(zs::Request::Block(zs::HashOrHeight::from(hash)))
|
|
||||||
.await;
|
|
||||||
|
|
||||||
let block_in_chain = match block_state_req {
|
|
||||||
Ok(zs::Response::Block(block)) => block,
|
|
||||||
_ => None,
|
|
||||||
};
|
|
||||||
|
|
||||||
// Block already in state, get out.
|
|
||||||
if block_in_chain.is_some() {
|
|
||||||
return Ok(false);
|
|
||||||
}
|
|
||||||
|
|
||||||
// We construct the block requests sequentially, waiting for the peer
|
|
||||||
// set to be ready to process each request. This ensures that we start
|
|
||||||
// block downloads in the order we want them (though they may resolve
|
|
||||||
// out of order), and it means that we respect backpressure. Otherwise,
|
|
||||||
// if we waited for readiness and did the service call in the spawned
|
|
||||||
// tasks, all of the spawned tasks would race each other waiting for the
|
|
||||||
// network to become ready.
|
|
||||||
tracing::debug!("waiting to request block");
|
|
||||||
let block_req = self
|
|
||||||
.network
|
|
||||||
.ready_and()
|
|
||||||
.await
|
|
||||||
.map_err(|e| eyre!(e))?
|
|
||||||
.call(zn::Request::BlocksByHash(std::iter::once(hash).collect()));
|
|
||||||
tracing::debug!("requested block");
|
|
||||||
|
|
||||||
// This oneshot is used to signal cancellation to the download task.
|
// This oneshot is used to signal cancellation to the download task.
|
||||||
let (cancel_tx, mut cancel_rx) = oneshot::channel::<()>();
|
let (cancel_tx, mut cancel_rx) = oneshot::channel::<()>();
|
||||||
|
|
||||||
|
let mut state = self.state.clone();
|
||||||
|
let mut network = self.network.clone();
|
||||||
let mut verifier = self.verifier.clone();
|
let mut verifier = self.verifier.clone();
|
||||||
let task = tokio::spawn(
|
|
||||||
async move {
|
|
||||||
let rsp = tokio::select! {
|
|
||||||
_ = &mut cancel_rx => {
|
|
||||||
tracing::trace!("task cancelled prior to download completion");
|
|
||||||
metrics::counter!("gossip.cancelled.download.count", 1);
|
|
||||||
return Err("canceled block_fetch_verify".into())
|
|
||||||
}
|
|
||||||
rsp = block_req => rsp?,
|
|
||||||
};
|
|
||||||
|
|
||||||
let block = if let zn::Response::Blocks(blocks) = rsp {
|
let fut = async move {
|
||||||
blocks
|
// Check if the block is already in the state.
|
||||||
.into_iter()
|
match state.oneshot(zs::Request::Depth(hash.into())).await {
|
||||||
.next()
|
Ok(zs::Response::Depth(None)) => Ok(()),
|
||||||
.expect("successful response has the block in it")
|
Ok(zs::Response::Depth(Some(_))) => Err("already present".into()),
|
||||||
} else {
|
Err(e) => Err(e),
|
||||||
unreachable!("wrong response to block request");
|
}?;
|
||||||
};
|
|
||||||
metrics::counter!("gossip.downloaded.block.count", 1);
|
|
||||||
|
|
||||||
let rsp = verifier.ready_and().await?.call(block);
|
let block = if let zn::Response::Blocks(blocks) = network
|
||||||
let verification = tokio::select! {
|
.oneshot(zn::Request::BlocksByHash(std::iter::once(hash).collect()))
|
||||||
_ = &mut cancel_rx => {
|
.await?
|
||||||
tracing::trace!("task cancelled prior to verification");
|
{
|
||||||
metrics::counter!("gossip.cancelled.verify.count", 1);
|
blocks
|
||||||
return Err("canceled block_fetch_verify".into())
|
.into_iter()
|
||||||
}
|
.next()
|
||||||
verification = rsp => verification,
|
.expect("successful response has the block in it")
|
||||||
};
|
} else {
|
||||||
if verification.is_ok() {
|
unreachable!("wrong response to block request");
|
||||||
metrics::counter!("sync.verified.block.count", 1);
|
};
|
||||||
|
metrics::counter!("gossip.downloaded.block.count", 1);
|
||||||
|
|
||||||
|
verifier.oneshot(block).await
|
||||||
|
}
|
||||||
|
.map_ok(|hash| {
|
||||||
|
tracing::info!(?hash, "verified advertised block");
|
||||||
|
metrics::counter!("gossip.verified.block.count", 1);
|
||||||
|
})
|
||||||
|
// Tack the hash onto the error so we can remove the cancel handle
|
||||||
|
// on failure as well as on success.
|
||||||
|
.map_err(move |e| (e, hash))
|
||||||
|
.in_current_span();
|
||||||
|
|
||||||
|
let task = tokio::spawn(async move {
|
||||||
|
tokio::select! {
|
||||||
|
_ = &mut cancel_rx => {
|
||||||
|
tracing::trace!("task cancelled prior to completion");
|
||||||
|
metrics::counter!("gossip.cancelled.count", 1);
|
||||||
}
|
}
|
||||||
|
verification = fut => verification,
|
||||||
verification
|
|
||||||
}
|
}
|
||||||
.in_current_span()
|
});
|
||||||
// Tack the hash onto the error so we can remove the cancel handle
|
|
||||||
// on failure as well as on success.
|
|
||||||
.map_err(move |e| (e, hash)),
|
|
||||||
);
|
|
||||||
|
|
||||||
self.pending.push(task);
|
self.pending.push(task);
|
||||||
// XXX replace with expect_none when stable
|
// XXX replace with expect_none when stable
|
||||||
|
@ -201,6 +167,6 @@ where
|
||||||
"blocks are only queued once"
|
"blocks are only queued once"
|
||||||
);
|
);
|
||||||
|
|
||||||
Ok(true)
|
true
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
Loading…
Reference in New Issue