Merge pull request #225 from ethcore/sync_block_writer_up

Support 'unordered' blocks import
This commit is contained in:
Marek Kotewicz 2016-11-30 14:36:26 +01:00 committed by GitHub
commit d3e4941a19
8 changed files with 173 additions and 56 deletions

View File

@ -1,4 +1,5 @@
use std::{io, fs, path};
use std::collections::BTreeSet;
use ser::{ReadIterator, deserialize_iterator, Error as ReaderError};
use block::Block;
use fs::read_blk_dir;
@ -25,9 +26,11 @@ impl Iterator for BlkFile {
}
pub fn open_blk_dir<P>(path: P) -> Result<BlkDir, io::Error> where P: AsRef<path::Path> {
let iter = try!(read_blk_dir(path))
let files = read_blk_dir(path)?.collect::<Result<BTreeSet<_>, _>>()?;
let iter = files.into_iter()
// flatten results...
.flat_map(|entry| entry.and_then(|file| open_blk_file(file.path)))
.flat_map(|file| open_blk_file(file.path))
// flat iterators over each block in each file
.flat_map(|file| file);

View File

@ -1,4 +1,4 @@
use std::{io, fs, path};
use std::{io, fs, path, cmp};
/// Creates an iterator over all blk .dat files
pub fn read_blk_dir<P>(path: P) -> Result<ReadBlkDir, io::Error> where P: AsRef<path::Path> {
@ -13,10 +13,23 @@ pub struct ReadBlkDir {
read_dir: fs::ReadDir,
}
#[derive(PartialEq, Eq)]
pub struct BlkEntry {
pub path: path::PathBuf,
}
impl cmp::PartialOrd for BlkEntry {
fn partial_cmp(&self, other: &Self) -> Option<cmp::Ordering> {
cmp::PartialOrd::partial_cmp(&self.path, &other.path)
}
}
impl cmp::Ord for BlkEntry {
fn cmp(&self, other: &Self) -> cmp::Ordering {
cmp::Ord::cmp(&self.path, &other.path)
}
}
fn is_blk_file_name(file_name: &str) -> bool {
if file_name.len() != 12 || !file_name.starts_with("blk") || !file_name.ends_with(".dat") {
return false;

View File

@ -31,8 +31,8 @@ impl ConsensusParams {
}
pub fn is_bip30_exception(&self, hash: &H256, height: u32) -> bool {
(height == 91842 && hash == &H256::from_reversed_str("0x00000000000a4d0a398161ffc163c503763b1f4360639393e0e4c8e300e0caec")) ||
(height == 91880 && hash == &H256::from_reversed_str("0x00000000000743f190a18c5577a3c2d2a1f610ae9601ac046a38084ccb7cd721"))
(height == 91842 && hash == &H256::from_reversed_str("00000000000a4d0a398161ffc163c503763b1f4360639393e0e4c8e300e0caec")) ||
(height == 91880 && hash == &H256::from_reversed_str("00000000000743f190a18c5577a3c2d2a1f610ae9601ac046a38084ccb7cd721"))
}
}

View File

@ -13,7 +13,6 @@ pub fn import(cfg: Config, matches: &ArgMatches) -> Result<(), String> {
let blk_path = matches.value_of("PATH").expect("PATH is required in cli.yml; qed");
let blk_dir = try!(::import::open_blk_dir(blk_path).map_err(|_| "Import directory does not exist".to_owned()));
let mut counter = 0;
let mut skipped = 0;
for blk in blk_dir {
// TODO: verify magic!
let blk = try!(blk.map_err(|_| "Cannot read block".to_owned()));
@ -24,14 +23,12 @@ pub fn import(cfg: Config, matches: &ArgMatches) -> Result<(), String> {
info!("Imported {} blocks", counter);
}
}
Err(Error::OutOfOrderBlock) => {
skipped += 1;
},
Err(Error::TooManyOrphanBlocks) => return Err("Too many orphan (unordered) blocks".into()),
Err(_) => return Err("Cannot append block".into()),
}
}
info!("Finished import of {} blocks. Skipped {} blocks.", counter, skipped);
info!("Finished import of {} blocks", counter);
Ok(())
}

View File

@ -1,45 +1,108 @@
use std::sync::Arc;
use std::collections::VecDeque;
use parking_lot::Mutex;
use chain;
use db;
use network::Magic;
use verification::{Verify, ChainVerifier};
use orphan_blocks_pool::OrphanBlocksPool;
use synchronization_verifier::{Verifier, SyncVerifier, VerificationSink};
use primitives::hash::H256;
use super::Error;
pub const MAX_ORPHANED_BLOCKS: usize = 1024;
pub struct BlocksWriter {
storage: Arc<db::Store>,
verifier: ChainVerifier,
storage: db::SharedStore,
orphaned_blocks_pool: OrphanBlocksPool,
verifier: SyncVerifier<BlocksWriterSink>,
sink: Arc<Mutex<BlocksWriterSink>>,
}
struct BlocksWriterSink {
storage: db::SharedStore,
err: Option<Error>,
}
impl BlocksWriter {
pub fn new(storage: db::SharedStore, network: Magic) -> BlocksWriter {
let sink = Arc::new(Mutex::new(BlocksWriterSink::new(storage.clone())));
let verifier = SyncVerifier::new(network, storage.clone(), sink.clone());
BlocksWriter {
storage: storage.clone(),
verifier: ChainVerifier::new(storage, network),
storage: storage,
orphaned_blocks_pool: OrphanBlocksPool::new(),
verifier: verifier,
sink: sink,
}
}
pub fn append_block(&mut self, block: chain::Block) -> Result<(), Error> {
let indexed_block: db::IndexedBlock = block.into();
// TODO: share same verification code with synchronization_client
if self.storage.best_block().map_or(false, |bb| bb.hash != indexed_block.header().previous_header_hash) {
return Err(Error::OutOfOrderBlock);
// verify && insert only if parent block is already in the storage
if !self.storage.contains_block(db::BlockRef::Hash(indexed_block.header().previous_header_hash.clone())) {
self.orphaned_blocks_pool.insert_orphaned_block(indexed_block.hash().clone(), indexed_block);
// we can't hold many orphaned blocks in memory during import
if self.orphaned_blocks_pool.len() > MAX_ORPHANED_BLOCKS {
return Err(Error::TooManyOrphanBlocks);
}
return Ok(());
}
match self.verifier.verify(&indexed_block) {
Err(err) => Err(Error::Verification(err)),
Ok(_chain) => { try!(self.storage.insert_indexed_block(&indexed_block).map_err(Error::Database)); Ok(()) }
// verify && insert block && all its orphan children
let mut verification_queue: VecDeque<db::IndexedBlock> = self.orphaned_blocks_pool.remove_blocks_for_parent(indexed_block.hash()).into_iter().map(|(_, b)| b).collect();
verification_queue.push_front(indexed_block);
while let Some(block) = verification_queue.pop_front() {
self.verifier.verify_block(block);
if let Some(err) = self.sink.lock().error() {
return Err(err);
}
}
Ok(())
}
}
impl BlocksWriterSink {
pub fn new(storage: db::SharedStore) -> Self {
BlocksWriterSink {
storage: storage,
err: None,
}
}
pub fn error(&mut self) -> Option<Error> {
self.err.take()
}
}
impl VerificationSink for BlocksWriterSink {
fn on_block_verification_success(&mut self, block: db::IndexedBlock) {
if let Err(err) = self.storage.insert_indexed_block(&block) {
self.err = Some(Error::Database(err));
}
}
fn on_block_verification_error(&mut self, err: &str, _hash: &H256) {
self.err = Some(Error::Verification(err.into()));
}
fn on_transaction_verification_success(&mut self, _transaction: chain::Transaction) {
unreachable!("not intended to verify transactions")
}
fn on_transaction_verification_error(&mut self, _err: &str, _hash: &H256) {
unreachable!("not intended to verify transactions")
}
}
#[cfg(test)]
mod tests {
use std::sync::Arc;
use db::{self, Store};
use network::Magic;
use {test_data, verification};
use test_data;
use super::super::Error;
use super::BlocksWriter;
use super::{BlocksWriter, MAX_ORPHANED_BLOCKS};
#[test]
fn blocks_writer_appends_blocks() {
@ -52,11 +115,15 @@ mod tests {
#[test]
fn blocks_writer_verification_error() {
let db = Arc::new(db::TestStorage::with_genesis_block());
let blocks = test_data::build_n_empty_blocks_from_genesis((MAX_ORPHANED_BLOCKS + 2) as u32, 1);
let mut blocks_target = BlocksWriter::new(db.clone(), Magic::Testnet);
match blocks_target.append_block(test_data::block_h2()).unwrap_err() {
Error::OutOfOrderBlock => (),
_ => panic!("Unexpected error"),
};
for (index, block) in blocks.into_iter().skip(1).enumerate() {
match blocks_target.append_block(block) {
Err(Error::TooManyOrphanBlocks) if index == MAX_ORPHANED_BLOCKS => (),
Ok(_) if index != MAX_ORPHANED_BLOCKS => (),
_ => panic!("unexpected"),
}
}
assert_eq!(db.best_block().expect("Block is inserted").number, 0);
}
@ -69,7 +136,7 @@ mod tests {
.header().parent(test_data::genesis().hash()).build()
.build();
match blocks_target.append_block(wrong_block).unwrap_err() {
Error::Verification(verification::Error::Empty) => (),
Error::Verification(_) => (),
_ => panic!("Unexpected error"),
};
assert_eq!(db.best_block().expect("Block is inserted").number, 0);

View File

@ -51,12 +51,12 @@ use network::Magic;
/// Sync errors.
#[derive(Debug)]
pub enum Error {
/// Out of order block.
OutOfOrderBlock,
/// Too many orphan blocks.
TooManyOrphanBlocks,
/// Database error.
Database(db::Error),
/// Block verification error.
Verification(verification::Error),
Verification(String),
}
/// Create blocks writer.
@ -74,11 +74,11 @@ pub fn create_sync_connection_factory(handle: &Handle, network: Magic, db: db::S
use synchronization_client::{SynchronizationClient, SynchronizationClientCore, Config as SynchronizationConfig};
use synchronization_verifier::AsyncVerifier;
let sync_chain = Arc::new(RwLock::new(SyncChain::new(db)));
let sync_chain = Arc::new(RwLock::new(SyncChain::new(db.clone())));
let sync_executor = SyncExecutor::new(sync_chain.clone());
let sync_server = Arc::new(SynchronizationServer::new(sync_chain.clone(), sync_executor.clone()));
let sync_client_core = SynchronizationClientCore::new(SynchronizationConfig::new(), handle, sync_executor.clone(), sync_chain.clone());
let verifier = AsyncVerifier::new(network, sync_chain, sync_client_core.clone());
let verifier = AsyncVerifier::new(network, db, sync_client_core.clone());
let sync_client = SynchronizationClient::new(sync_client_core, verifier);
let sync_node = Arc::new(SyncNode::new(sync_server, sync_client, sync_executor));
SyncConnectionFactory::with_local_node(sync_node)

View File

@ -24,7 +24,6 @@ impl OrphanBlocksPool {
}
}
#[cfg(test)]
/// Get total number of blocks in pool
pub fn len(&self) -> usize {
self.orphaned_blocks.len()

View File

@ -6,8 +6,7 @@ use chain::Transaction;
use network::Magic;
use primitives::hash::H256;
use verification::{ChainVerifier, Verify as VerificationVerify, Chain};
use synchronization_chain::ChainRef;
use db::IndexedBlock;
use db::{SharedStore, IndexedBlock};
/// Verification events sink
pub trait VerificationSink : Send + 'static {
@ -49,9 +48,8 @@ pub struct AsyncVerifier {
impl AsyncVerifier {
/// Create new async verifier
pub fn new<T: VerificationSink>(network: Magic, chain: ChainRef, sink: Arc<Mutex<T>>) -> Self {
pub fn new<T: VerificationSink>(network: Magic, storage: SharedStore, sink: Arc<Mutex<T>>) -> Self {
let (verification_work_sender, verification_work_receiver) = channel();
let storage = chain.read().storage();
let verifier = ChainVerifier::new(storage, network);
AsyncVerifier {
verification_work_sender: verification_work_sender,
@ -68,30 +66,14 @@ impl AsyncVerifier {
fn verification_worker_proc<T: VerificationSink>(sink: Arc<Mutex<T>>, verifier: ChainVerifier, work_receiver: Receiver<VerificationTask>) {
while let Ok(task) = work_receiver.recv() {
match task {
VerificationTask::VerifyBlock(block) => {
// verify block
match verifier.verify(&block) {
Ok(Chain::Main) | Ok(Chain::Side) => {
sink.lock().on_block_verification_success(block)
},
Ok(Chain::Orphan) => {
unreachable!("sync will never put orphaned blocks to verification queue");
},
Err(e) => {
sink.lock().on_block_verification_error(&format!("{:?}", e), &block.hash())
}
}
},
VerificationTask::VerifyTransaction(transaction) => {
// TODO: add verification here
sink.lock().on_transaction_verification_error("unimplemented", &transaction.hash())
}
VerificationTask::Stop => break,
_ => execute_verification_task(&sink, &verifier, task),
}
}
}
}
impl Drop for AsyncVerifier {
fn drop(&mut self) {
if let Some(join_handle) = self.verification_worker_thread.take() {
@ -118,6 +100,62 @@ impl Verifier for AsyncVerifier {
}
}
/// Synchronous synchronization verifier
pub struct SyncVerifier<T: VerificationSink> {
/// Verifier
verifier: ChainVerifier,
/// Verification sink
sink: Arc<Mutex<T>>,
}
impl<T> SyncVerifier<T> where T: VerificationSink {
/// Create new sync verifier
pub fn new(network: Magic, storage: SharedStore, sink: Arc<Mutex<T>>) -> Self {
let verifier = ChainVerifier::new(storage, network);
SyncVerifier {
verifier: verifier,
sink: sink,
}
}
}
impl<T> Verifier for SyncVerifier<T> where T: VerificationSink {
/// Verify block
fn verify_block(&self, block: IndexedBlock) {
execute_verification_task(&self.sink, &self.verifier, VerificationTask::VerifyBlock(block))
}
/// Verify transaction
fn verify_transaction(&self, transaction: Transaction) {
execute_verification_task(&self.sink, &self.verifier, VerificationTask::VerifyTransaction(transaction))
}
}
/// Execute single verification task
fn execute_verification_task<T: VerificationSink>(sink: &Arc<Mutex<T>>, verifier: &ChainVerifier, task: VerificationTask) {
match task {
VerificationTask::VerifyBlock(block) => {
// verify block
match verifier.verify(&block) {
Ok(Chain::Main) | Ok(Chain::Side) => {
sink.lock().on_block_verification_success(block)
},
Ok(Chain::Orphan) => {
unreachable!("sync will never put orphaned blocks to verification queue");
},
Err(e) => {
sink.lock().on_block_verification_error(&format!("{:?}", e), &block.hash())
}
}
},
VerificationTask::VerifyTransaction(transaction) => {
// TODO: add verification here
sink.lock().on_transaction_verification_error("unimplemented", &transaction.hash())
},
_ => unreachable!("must be checked by caller"),
}
}
#[cfg(test)]
pub mod tests {
use std::sync::Arc;