zcash-sync/src/scan.rs

361 lines
13 KiB
Rust
Raw Normal View History

2021-06-26 02:52:03 -07:00
use crate::builder::BlockProcessor;
use crate::chain::{DecryptedBlock, Nf, NfRef, TRIAL_DECRYPTIONS};
2022-07-21 18:08:29 -07:00
use crate::db::{DbAdapter, ReceivedNote};
2022-08-16 07:47:48 -07:00
use std::cmp::Ordering;
2022-07-21 18:08:29 -07:00
2021-07-16 01:42:29 -07:00
use crate::transaction::retrieve_tx_info;
2021-06-26 02:52:03 -07:00
use crate::{
2022-07-21 18:08:29 -07:00
connect_lightwalletd, download_chain, get_latest_height, CompactBlock, DecryptNode, Witness,
2021-06-26 02:52:03 -07:00
};
2021-06-21 17:33:13 -07:00
use ff::PrimeField;
2022-07-21 18:08:29 -07:00
2022-08-21 09:40:14 -07:00
use lazy_static::lazy_static;
use std::collections::HashMap;
2021-07-16 01:42:29 -07:00
use std::panic;
2021-06-24 05:08:20 -07:00
use std::sync::Arc;
2021-06-26 02:52:03 -07:00
use std::time::Instant;
use tokio::runtime::{Builder, Runtime};
2021-06-26 02:52:03 -07:00
use tokio::sync::mpsc;
2021-06-24 05:08:20 -07:00
use tokio::sync::Mutex;
2022-06-07 09:58:24 -07:00
use zcash_params::coin::{get_coin_chain, CoinType};
2021-06-18 01:17:41 -07:00
2022-07-21 18:08:29 -07:00
use zcash_primitives::sapling::Node;
2021-06-18 01:17:41 -07:00
2022-07-09 09:12:34 -07:00
pub struct Blocks(pub Vec<CompactBlock>);
2021-06-21 17:33:13 -07:00
lazy_static! {
static ref DECRYPTER_RUNTIME: Runtime = Builder::new_multi_thread().build().unwrap();
}
2021-07-27 22:07:20 -07:00
#[derive(Debug)]
struct TxIdSet(Vec<u32>);
2021-06-21 17:33:13 -07:00
impl std::fmt::Debug for Blocks {
fn fmt(&self, f: &mut std::fmt::Formatter<'_>) -> std::fmt::Result {
write!(f, "Blocks of len {}", self.0.len())
}
}
2022-06-08 05:48:16 -07:00
pub type ProgressCallback = dyn Fn(u32) + Send;
pub type AMProgressCallback = Arc<Mutex<ProgressCallback>>;
2021-06-21 17:33:13 -07:00
2021-08-10 04:51:39 -07:00
#[derive(PartialEq, PartialOrd, Debug, Hash, Eq)]
pub struct TxIdHeight {
id_tx: u32,
2021-08-10 04:51:39 -07:00
height: u32,
index: u32,
}
2021-06-26 02:52:03 -07:00
pub async fn sync_async(
2022-03-07 06:47:06 -08:00
coin_type: CoinType,
2022-07-14 18:12:25 -07:00
_chunk_size: u32,
2021-07-09 22:44:13 -07:00
get_tx: bool,
2021-06-26 02:52:03 -07:00
db_path: &str,
target_height_offset: u32,
2022-07-30 16:11:58 -07:00
max_cost: u32,
2022-06-08 05:48:16 -07:00
progress_callback: AMProgressCallback,
2022-08-30 07:00:15 -07:00
cancel: &'static std::sync::Mutex<bool>,
2021-07-16 01:42:29 -07:00
ld_url: &str,
2021-06-26 02:52:03 -07:00
) -> anyhow::Result<()> {
2021-07-09 06:33:05 -07:00
let ld_url = ld_url.to_owned();
2021-06-21 17:33:13 -07:00
let db_path = db_path.to_string();
2022-03-07 06:47:06 -08:00
let network = {
let chain = get_coin_chain(coin_type);
2022-06-08 05:48:16 -07:00
*chain.network()
2022-03-07 06:47:06 -08:00
};
2021-06-21 17:33:13 -07:00
2021-07-09 06:33:05 -07:00
let mut client = connect_lightwalletd(&ld_url).await?;
2022-07-09 09:12:34 -07:00
let (start_height, prev_hash, vks) = {
2022-04-19 09:47:08 -07:00
let db = DbAdapter::new(coin_type, &db_path)?;
2021-06-26 02:52:03 -07:00
let height = db.get_db_height()?;
2021-06-29 00:04:12 -07:00
let hash = db.get_db_hash(height)?;
2021-07-27 22:07:20 -07:00
let vks = db.get_fvks()?;
(height, hash, vks)
2021-06-24 05:08:20 -07:00
};
2021-06-21 17:33:13 -07:00
let end_height = get_latest_height(&mut client).await?;
2021-06-24 05:08:20 -07:00
let end_height = (end_height - target_height_offset).max(start_height);
2022-07-13 21:21:20 -07:00
if start_height >= end_height {
return Ok(());
}
2022-08-03 08:30:34 -07:00
let n_ivks = vks.len();
2021-06-21 17:33:13 -07:00
2022-07-30 16:11:58 -07:00
let decrypter = DecryptNode::new(vks, max_cost);
2021-06-29 00:04:12 -07:00
let (decryptor_tx, mut decryptor_rx) = mpsc::channel::<Blocks>(1);
let (processor_tx, mut processor_rx) = mpsc::channel::<Vec<DecryptedBlock>>(1);
2021-06-21 17:33:13 -07:00
2021-07-27 22:07:20 -07:00
let db_path2 = db_path.clone();
2021-06-24 05:08:20 -07:00
let downloader = tokio::spawn(async move {
2022-07-09 09:12:34 -07:00
log::info!("download_scheduler");
download_chain(
&mut client,
2022-08-03 08:30:34 -07:00
n_ivks,
2022-07-09 09:12:34 -07:00
start_height,
end_height,
prev_hash,
2022-08-31 08:35:21 -07:00
max_cost,
decryptor_tx,
2022-07-21 18:08:29 -07:00
cancel,
2022-07-09 09:12:34 -07:00
)
.await?;
2021-06-24 05:08:20 -07:00
Ok::<_, anyhow::Error>(())
2021-06-21 17:33:13 -07:00
});
2021-06-24 05:08:20 -07:00
let proc_callback = progress_callback.clone();
let decryptor = DECRYPTER_RUNTIME.spawn(async move {
while let Some(blocks) = decryptor_rx.recv().await {
let dec_blocks = decrypter.decrypt_blocks(&network, blocks.0); // this function may block
let batch_decrypt_elapsed: usize = dec_blocks.iter().map(|b| b.elapsed).sum();
log::info!(" Batch Decrypt: {} ms", batch_decrypt_elapsed);
let _ = processor_tx.send(dec_blocks).await;
}
Ok::<_, anyhow::Error>(())
});
2021-06-24 05:08:20 -07:00
let processor = tokio::spawn(async move {
2022-04-19 09:47:08 -07:00
let mut db = DbAdapter::new(coin_type, &db_path2)?;
2021-06-24 05:08:20 -07:00
let mut nfs = db.get_nullifiers()?;
while let Some(dec_blocks) = processor_rx.recv().await {
if dec_blocks.is_empty() {
2021-06-26 02:52:03 -07:00
continue;
}
2022-07-09 01:26:25 -07:00
let (mut tree, witnesses) = db.get_tree()?;
let mut bp = BlockProcessor::new(&tree, &witnesses);
let mut absolute_position_at_block_start = tree.get_position();
log::info!("start processing - {}", dec_blocks[0].height);
2022-03-14 05:50:56 -07:00
log::info!("Time {:?}", chrono::offset::Local::now());
let start = Instant::now();
2021-06-21 17:33:13 -07:00
let mut new_ids_tx: HashMap<u32, TxIdHeight> = HashMap::new();
2021-06-26 02:52:03 -07:00
let mut witnesses: Vec<Witness> = vec![];
2021-09-02 19:56:10 -07:00
2021-11-11 17:39:50 -08:00
{
// db tx scope
2021-09-02 19:56:10 -07:00
let db_tx = db.begin_transaction()?;
2022-08-16 07:47:48 -07:00
let outputs = dec_blocks
.iter()
.map(|db| db.count_outputs as usize)
.sum::<usize>();
2022-08-30 07:00:15 -07:00
{
let mut dc = TRIAL_DECRYPTIONS.lock().unwrap();
*dc += n_ivks * outputs;
}
2021-09-02 19:56:10 -07:00
for b in dec_blocks.iter() {
let mut my_nfs: Vec<Nf> = vec![];
for nf in b.spends.iter() {
if let Some(&nf_ref) = nfs.get(nf) {
log::info!("NF FOUND {} {}", nf_ref.id_note, b.height);
DbAdapter::mark_spent(nf_ref.id_note, b.height, &db_tx)?;
my_nfs.push(*nf);
nfs.remove(nf);
}
}
if !b.notes.is_empty() {
log::debug!("{} {}", b.height, b.notes.len());
2021-06-24 05:08:20 -07:00
}
2021-06-26 02:52:03 -07:00
2021-09-02 19:56:10 -07:00
for n in b.notes.iter() {
let p = absolute_position_at_block_start + n.position_in_block;
let note = &n.note;
let rcm = note.rcm().to_repr();
let nf = note.nf(&n.ivk.fvk.vk, p as u64);
let id_tx = DbAdapter::store_transaction(
&n.txid,
n.account,
n.height,
b.compact_block.time,
n.tx_index as u32,
&db_tx,
)?;
2021-11-11 17:39:50 -08:00
new_ids_tx.insert(
id_tx,
2021-11-11 17:39:50 -08:00
TxIdHeight {
id_tx,
height: n.height,
index: n.tx_index as u32,
},
);
2021-09-02 19:56:10 -07:00
let id_note = DbAdapter::store_received_note(
&ReceivedNote {
account: n.account,
height: n.height,
output_index: n.output_index as u32,
diversifier: n.pa.diversifier().0.to_vec(),
value: note.value,
rcm: rcm.to_vec(),
nf: nf.0.to_vec(),
spent: None,
},
id_tx,
n.position_in_block,
2021-11-11 17:39:50 -08:00
&db_tx,
2021-09-02 19:56:10 -07:00
)?;
DbAdapter::add_value(id_tx, note.value as i64, &db_tx)?;
nfs.insert(
Nf(nf.0),
NfRef {
id_note,
account: n.account,
},
);
let w = Witness::new(p as usize, id_note, Some(n.clone()));
witnesses.push(w);
}
2021-06-26 02:52:03 -07:00
if !my_nfs.is_empty() {
2021-09-02 19:56:10 -07:00
for (tx_index, tx) in b.compact_block.vtx.iter().enumerate() {
for cs in tx.spends.iter() {
let mut nf = [0u8; 32];
nf.copy_from_slice(&cs.nf);
let nf = Nf(nf);
if my_nfs.contains(&nf) {
2021-11-11 17:39:50 -08:00
let (account, note_value) =
DbAdapter::get_received_note_value(&nf, &db_tx)?;
2021-09-02 19:56:10 -07:00
let txid = &*tx.hash;
let id_tx = DbAdapter::store_transaction(
txid,
account,
b.height,
b.compact_block.time,
tx_index as u32,
2021-11-11 17:39:50 -08:00
&db_tx,
2021-09-02 19:56:10 -07:00
)?;
2021-11-11 17:39:50 -08:00
new_ids_tx.insert(
id_tx,
2021-11-11 17:39:50 -08:00
TxIdHeight {
id_tx,
height: b.height,
index: tx_index as u32,
},
);
2021-09-02 19:56:10 -07:00
DbAdapter::add_value(id_tx, -(note_value as i64), &db_tx)?;
2021-08-10 04:51:39 -07:00
}
2021-06-26 02:52:03 -07:00
}
}
}
2021-09-02 19:56:10 -07:00
absolute_position_at_block_start += b.count_outputs as usize;
2021-06-26 02:52:03 -07:00
}
2021-09-02 19:56:10 -07:00
log::info!("Dec end : {}", start.elapsed().as_millis());
2021-06-26 02:52:03 -07:00
2021-09-02 19:56:10 -07:00
db_tx.commit()?;
2021-06-21 17:33:13 -07:00
}
2021-07-27 22:07:20 -07:00
let start = Instant::now();
2021-06-21 17:33:13 -07:00
let mut nodes: Vec<Node> = vec![];
for block in dec_blocks.iter() {
let cb = &block.compact_block;
2021-06-21 17:33:13 -07:00
for tx in cb.vtx.iter() {
for co in tx.outputs.iter() {
let mut cmu = [0u8; 32];
cmu.copy_from_slice(&co.cmu);
let node = Node::new(cmu);
nodes.push(node);
}
}
}
2021-06-26 02:52:03 -07:00
if !nodes.is_empty() {
bp.add_nodes(&mut nodes, &witnesses);
}
2021-06-28 21:49:00 -07:00
// println!("NOTES = {}", nodes.len());
2021-06-21 17:33:13 -07:00
2021-07-27 22:07:20 -07:00
log::info!("Witness : {}", start.elapsed().as_millis());
let start = Instant::now();
2021-09-11 23:21:34 -07:00
if get_tx && !new_ids_tx.is_empty() {
2021-11-11 17:39:50 -08:00
let mut ids: Vec<_> = new_ids_tx.into_iter().map(|(_, v)| v).collect();
ids.sort_by(|a, b| {
let c = a.height.cmp(&b.height);
if c == Ordering::Equal {
return a.index.cmp(&b.index);
}
2022-06-08 05:48:16 -07:00
c
});
let ids: Vec<_> = ids.into_iter().map(|e| e.id_tx).collect();
2022-07-09 09:12:34 -07:00
let mut client = connect_lightwalletd(&ld_url).await?;
2022-06-07 09:58:24 -07:00
retrieve_tx_info(coin_type, &mut client, &db_path2, &ids)
.await
.unwrap();
2021-07-27 22:07:20 -07:00
}
log::info!("Transaction Details : {}", start.elapsed().as_millis());
2022-07-09 01:26:25 -07:00
let (new_tree, new_witnesses) = bp.finalize();
tree = new_tree;
witnesses = new_witnesses;
2021-06-21 17:33:13 -07:00
if let Some(dec_block) = dec_blocks.last() {
2022-07-16 20:23:56 -07:00
{
let block = &dec_block.compact_block;
2022-07-16 20:23:56 -07:00
let mut db_transaction = db.begin_transaction()?;
let height = block.height as u32;
for w in witnesses.iter() {
DbAdapter::store_witnesses(&db_transaction, w, height, w.id_note)?;
}
DbAdapter::store_block(
&mut db_transaction,
height,
&block.hash,
block.time,
&tree,
)?;
db_transaction.commit()?;
// db_transaction is dropped here
2022-07-09 01:26:25 -07:00
}
log::info!("progress: {}", dec_block.height);
2022-07-16 20:23:56 -07:00
let callback = proc_callback.lock().await;
callback(dec_block.height as u32);
2021-06-24 05:08:20 -07:00
}
2021-06-21 17:33:13 -07:00
}
2021-06-26 02:52:03 -07:00
let callback = progress_callback.lock().await;
callback(end_height);
2021-06-24 05:08:20 -07:00
2021-07-16 01:42:29 -07:00
db.purge_old_witnesses(end_height - 100)?;
2021-07-27 22:07:20 -07:00
2021-06-24 05:08:20 -07:00
Ok::<_, anyhow::Error>(())
2021-06-21 17:33:13 -07:00
});
2022-08-18 21:07:55 -07:00
let res = tokio::try_join!(downloader, decryptor, processor);
2021-06-24 05:08:20 -07:00
match res {
2022-08-18 21:07:55 -07:00
Ok((d, dc, p)) => {
2021-06-26 02:52:03 -07:00
if let Err(err) = d {
log::info!("Downloader error = {}", err);
return Err(err);
}
2022-08-18 21:07:55 -07:00
if let Err(err) = dc {
log::info!("Decryptor error = {}", err);
return Err(err);
}
2021-06-26 02:52:03 -07:00
if let Err(err) = p {
log::info!("Processor error = {}", err);
return Err(err);
}
}
Err(err) => {
log::info!("Sync error = {}", err);
2021-06-28 21:49:00 -07:00
if err.is_panic() {
panic::resume_unwind(err.into_panic());
}
2021-06-26 02:52:03 -07:00
anyhow::bail!("Join Error");
2021-07-16 01:42:29 -07:00
}
2021-06-24 05:08:20 -07:00
}
2021-06-26 02:52:03 -07:00
log::info!("Sync completed");
2021-06-21 17:33:13 -07:00
Ok(())
}
2021-07-09 06:33:05 -07:00
pub async fn latest_height(ld_url: &str) -> anyhow::Result<u32> {
let mut client = connect_lightwalletd(ld_url).await?;
2021-06-24 05:08:20 -07:00
let height = get_latest_height(&mut client).await?;
Ok(height)
2021-06-21 17:33:13 -07:00
}