service.rs 9.21 KiB
Newer Older
Gav Wood's avatar
Gav Wood committed
// Copyright 2015-2017 Parity Technologies (UK) Ltd.
// This file is part of Parity.

// Parity is free software: you can redistribute it and/or modify
// it under the terms of the GNU General Public License as published by
// the Free Software Foundation, either version 3 of the License, or
// (at your option) any later version.

// Parity is distributed in the hope that it will be useful,
// but WITHOUT ANY WARRANTY; without even the implied warranty of
// MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.  See the
// GNU General Public License for more details.

// You should have received a copy of the GNU General Public License
// along with Parity.  If not, see <http://www.gnu.org/licenses/>.

//! Creates and registers client and network services.

Marek Kotewicz's avatar
Marek Kotewicz committed
use std::sync::Arc;
use std::path::Path;
Fredrik's avatar
Fredrik committed
use bigint::hash::H256;
use kvdb::KeyValueDB;
use kvdb_rocksdb::{Database, DatabaseConfig};
Arkadiy Paronyan's avatar
Arkadiy Paronyan committed
use spec::Spec;
use error::*;
use client::{Client, ClientConfig, ChainNotify};
use miner::Miner;
Nikolay Volf's avatar
Nikolay Volf committed

use snapshot::{ManifestData, RestorationStatus};
use snapshot::service::{Service as SnapshotService, ServiceParams as SnapServiceParams};
use std::sync::atomic::AtomicBool;
use ansi_term::Colour;

#[cfg(feature="ipc")]
use nanoipc;
Arkadiy Paronyan's avatar
Arkadiy Paronyan committed

Arkadiy Paronyan's avatar
Arkadiy Paronyan committed
/// Message type for external and internal events
keorn's avatar
keorn committed
#[derive(Clone, PartialEq, Eq, Debug)]
pub enum ClientIoMessage {
	/// Best Block Hash in chain has been changed
	NewChainHead,
Tomusdrw's avatar
Tomusdrw committed
	/// A block is ready
Arkadiy Paronyan's avatar
Arkadiy Paronyan committed
	BlockVerified,
Arkadiy Paronyan's avatar
Arkadiy Paronyan committed
	/// New transaction RLPs are ready to be imported
	NewTransactions(Vec<Bytes>, usize),
	/// Begin snapshot restoration
	BeginRestoration(ManifestData),
	/// Feed a state chunk to the snapshot service
	FeedStateChunk(H256, Bytes),
	/// Feed a block chunk to the snapshot service
	FeedBlockChunk(H256, Bytes),
	/// Take a snapshot for the block with given number.
	TakeSnapshot(u64),
keorn's avatar
keorn committed
	/// New consensus message received.
	NewMessage(Bytes)
Arkadiy Paronyan's avatar
Arkadiy Paronyan committed
/// Client service setup. Creates and registers client and network services with the IO subsystem.
Arkadiy Paronyan's avatar
Arkadiy Paronyan committed
pub struct ClientService {
	io_service: Arc<IoService<ClientIoMessage>>,
Arkadiy Paronyan's avatar
Arkadiy Paronyan committed
	client: Arc<Client>,
	snapshot: Arc<SnapshotService>,
	_stop_guard: ::devtools::StopGuard,
Arkadiy Paronyan's avatar
Arkadiy Paronyan committed
}

impl ClientService {
	/// Start the `ClientService`.
	pub fn start(
		config: ClientConfig,
		client_path: &Path,
		snapshot_path: &Path,
		ipc_path: &Path,
		miner: Arc<Miner>,
		) -> Result<ClientService, Error>
	{
		let io_service = IoService::<ClientIoMessage>::start()?;
		info!("Configured for {} using {} engine", Colour::White.bold().paint(spec.name.clone()), Colour::Yellow.bold().paint(spec.engine.name()));
		let mut db_config = DatabaseConfig::with_columns(::db::NUM_COLUMNS);

		// give all rocksdb cache to state column; everything else has its
		// own caches.
		if let Some(size) = config.db_cache_size {
			db_config.set_cache(::db::COL_STATE, size);
		}

Tomasz Drwięga's avatar
Tomasz Drwięga committed
		db_config.compaction = config.db_compaction.compaction_profile(client_path);
		db_config.wal = config.db_wal;
		let db = Arc::new(Database::open(
			&db_config,
			&client_path.to_str().expect("DB path could not be converted to string.")
		).map_err(::client::Error::Database)?);


		let pruning = config.pruning;
		let client = Client::new(config, &spec, db.clone(), miner, io_service.channel())?;

		let snapshot_params = SnapServiceParams {
			engine: spec.engine.clone(),
			genesis_block: spec.genesis_block(),
			pruning: pruning,
			channel: io_service.channel(),
			snapshot_root: snapshot_path.into(),
			db_restore: client.clone(),
		};
		let snapshot = Arc::new(SnapshotService::new(snapshot_params)?);
		let client_io = Arc::new(ClientIoHandler {
			client: client.clone(),
			snapshot: snapshot.clone(),
Arkadiy Paronyan's avatar
Arkadiy Paronyan committed
		});
		io_service.register_handler(client_io)?;
Arkadiy Paronyan's avatar
Arkadiy Paronyan committed

		spec.engine.register_client(Arc::downgrade(&client) as _);
keorn's avatar
keorn committed

		let stop_guard = ::devtools::StopGuard::new();
Arkadiy Paronyan's avatar
Arkadiy Paronyan committed
		run_ipc(ipc_path, client.clone(), snapshot.clone(), stop_guard.share());
Arkadiy Paronyan's avatar
Arkadiy Paronyan committed
		Ok(ClientService {
			io_service: Arc::new(io_service),
			client: client,
			snapshot: snapshot,
			_stop_guard: stop_guard,
Arkadiy Paronyan's avatar
Arkadiy Paronyan committed
		})
	}
	/// Get general IO interface
	pub fn register_io_handler(&self, handler: Arc<IoHandler<ClientIoMessage> + Send>) -> Result<(), IoError> {
		self.io_service.register_handler(handler)
	/// Get client interface
Arkadiy Paronyan's avatar
Arkadiy Paronyan committed
	pub fn client(&self) -> Arc<Client> {
		self.client.clone()
Arkadiy Paronyan's avatar
Arkadiy Paronyan committed
	}
	/// Get snapshot interface.
	pub fn snapshot_service(&self) -> Arc<SnapshotService> {
		self.snapshot.clone()
	}

	/// Get network service component
	pub fn io(&self) -> Arc<IoService<ClientIoMessage>> {
		self.io_service.clone()
	}

	/// Set the actor to be notified on certain chain events
	pub fn add_notify(&self, notify: Arc<ChainNotify>) {
		self.client.add_notify(notify);

	/// Get a handle to the database.
	pub fn db(&self) -> Arc<KeyValueDB> { self.database.clone() }
Arkadiy Paronyan's avatar
Arkadiy Paronyan committed
/// IO interface for the Client handler
Arkadiy Paronyan's avatar
Arkadiy Paronyan committed
struct ClientIoHandler {
	client: Arc<Client>,
	snapshot: Arc<SnapshotService>,
const CLIENT_TICK_TIMER: TimerToken = 0;
const SNAPSHOT_TICK_TIMER: TimerToken = 1;

const CLIENT_TICK_MS: u64 = 5000;
const SNAPSHOT_TICK_MS: u64 = 10000;
impl IoHandler<ClientIoMessage> for ClientIoHandler {
	fn initialize(&self, io: &IoContext<ClientIoMessage>) {
		io.register_timer(CLIENT_TICK_TIMER, CLIENT_TICK_MS).expect("Error registering client timer");
		io.register_timer(SNAPSHOT_TICK_TIMER, SNAPSHOT_TICK_MS).expect("Error registering snapshot timer");
	fn timeout(&self, _io: &IoContext<ClientIoMessage>, timer: TimerToken) {
			CLIENT_TICK_TIMER => {
				use snapshot::SnapshotService;
				let snapshot_restoration = if let RestorationStatus::Ongoing{..} = self.snapshot.status() { true } else { false };
				self.client.tick(snapshot_restoration)
			},
			SNAPSHOT_TICK_TIMER => self.snapshot.tick(),
			_ => warn!("IO service triggered unregistered timer '{}'", timer),
Gav Wood's avatar
Gav Wood committed
	}
Arkadiy Paronyan's avatar
Arkadiy Paronyan committed

	#[cfg_attr(feature="dev", allow(single_match))]
	fn message(&self, _io: &IoContext<ClientIoMessage>, net_message: &ClientIoMessage) {
		match *net_message {
			ClientIoMessage::BlockVerified => { self.client.import_verified_blocks(); }
			ClientIoMessage::NewTransactions(ref transactions, peer_id) => {
				self.client.import_queued_transactions(transactions, peer_id);
			ClientIoMessage::BeginRestoration(ref manifest) => {
				if let Err(e) = self.snapshot.init_restore(manifest.clone(), true) {
					warn!("Failed to initialize snapshot restoration: {}", e);
				}
			}
			ClientIoMessage::FeedStateChunk(ref hash, ref chunk) => self.snapshot.feed_state_chunk(*hash, chunk),
			ClientIoMessage::FeedBlockChunk(ref hash, ref chunk) => self.snapshot.feed_block_chunk(*hash, chunk),
			ClientIoMessage::TakeSnapshot(num) => {
				let client = self.client.clone();
				let snapshot = self.snapshot.clone();

				let res = thread::Builder::new().name("Periodic Snapshot".into()).spawn(move || {
					if let Err(e) = snapshot.take_snapshot(&*client, num) {
						warn!("Failed to take snapshot at block #{}: {}", num, e);
					}
				});

				if let Err(e) = res {
					debug!(target: "snapshot", "Failed to initialize periodic snapshot thread: {:?}", e);
keorn's avatar
keorn committed
			},
			ClientIoMessage::NewMessage(ref message) => if let Err(e) = self.client.engine().handle_message(message) {
				trace!(target: "poa", "Invalid message received: {}", e);
keorn's avatar
keorn committed
			},
			_ => {} // ignore other messages
#[cfg(feature="ipc")]
Arkadiy Paronyan's avatar
Arkadiy Paronyan committed
fn run_ipc(base_path: &Path, client: Arc<Client>, snapshot_service: Arc<SnapshotService>, stop: Arc<AtomicBool>) {
Nikolay Volf's avatar
Nikolay Volf committed
	let mut path = base_path.to_owned();
	path.push("parity-chain.ipc");
Nikolay Volf's avatar
Nikolay Volf committed
	let socket_addr = format!("ipc://{}", path.to_string_lossy());
Arkadiy Paronyan's avatar
Arkadiy Paronyan committed
	let s = stop.clone();
	::std::thread::spawn(move || {
		let mut worker = nanoipc::Worker::new(&(client as Arc<BlockChainClient>));
		worker.add_reqrep(&socket_addr).expect("Ipc expected to initialize with no issues");
Arkadiy Paronyan's avatar
Arkadiy Paronyan committed
		while !s.load(::std::sync::atomic::Ordering::Relaxed) {
			worker.poll();
		}
	});

	let mut path = base_path.to_owned();
	path.push("parity-snapshot.ipc");
	let socket_addr = format!("ipc://{}", path.to_string_lossy());
	::std::thread::spawn(move || {
		let mut worker = nanoipc::Worker::new(&(snapshot_service as Arc<::snapshot::SnapshotService>));
		worker.add_reqrep(&socket_addr).expect("Ipc expected to initialize with no issues");

		while !stop.load(::std::sync::atomic::Ordering::Relaxed) {
			worker.poll();
		}
	});
}

#[cfg(not(feature="ipc"))]
Arkadiy Paronyan's avatar
Arkadiy Paronyan committed
fn run_ipc(_base_path: &Path, _client: Arc<Client>, _snapshot_service: Arc<SnapshotService>, _stop: Arc<AtomicBool>) {
Nikolay Volf's avatar
Nikolay Volf committed
#[cfg(test)]
mod tests {
	use super::*;
	use tests::helpers::*;
	use devtools::*;
Arkadiy Paronyan's avatar
Arkadiy Paronyan committed
	use client::ClientConfig;
Nikolay Volf's avatar
Nikolay Volf committed
	use std::sync::Arc;
	use miner::Miner;
Nikolay Volf's avatar
Nikolay Volf committed

Nikolay Volf's avatar
Nikolay Volf committed
	#[test]
	fn it_can_be_started() {
Nikolay Volf's avatar
Nikolay Volf committed
		let temp_path = RandomTempPath::new();
		let path = temp_path.as_path().to_owned();
		let client_path = {
			let mut path = path.to_owned();
			path.push("client");
			path
		};

		let snapshot_path = {
			let mut path = path.to_owned();
			path.push("snapshot");
			path
		};
		let spec = get_test_spec();
		let service = ClientService::start(
			ClientConfig::default(),
			Arc::new(Miner::with_spec(&spec)),
Nikolay Volf's avatar
Nikolay Volf committed
		assert!(service.is_ok());
		drop(service.unwrap());
		::std::thread::park_timeout(::std::time::Duration::from_millis(100));
Nikolay Volf's avatar
Nikolay Volf committed
	}