generate transaction proofs from provider

This commit is contained in:
Robert Habermeier 2017-02-25 00:27:48 +01:00
parent ee7779df17
commit 92e5982127
12 changed files with 195 additions and 55 deletions

View File

@ -31,7 +31,7 @@ use ethcore::service::ClientIoMessage;
use ethcore::encoded; use ethcore::encoded;
use io::IoChannel; use io::IoChannel;
use util::{Bytes, H256, Mutex, RwLock}; use util::{Bytes, DBValue, H256, Mutex, RwLock};
use self::header_chain::HeaderChain; use self::header_chain::HeaderChain;
@ -293,6 +293,10 @@ impl ::provider::Provider for Client {
None None
} }
fn transaction_proof(&self, _req: ::request::TransactionProof) -> Option<Vec<DBValue>> {
None
}
fn ready_transactions(&self) -> Vec<::ethcore::transaction::PendingTransaction> { fn ready_transactions(&self) -> Vec<::ethcore::transaction::PendingTransaction> {
Vec::new() Vec::new()
} }

View File

@ -19,7 +19,7 @@
//! This uses a "Provider" to answer requests. //! This uses a "Provider" to answer requests.
//! See https://github.com/ethcore/parity/wiki/Light-Ethereum-Subprotocol-(LES) //! See https://github.com/ethcore/parity/wiki/Light-Ethereum-Subprotocol-(LES)
use ethcore::transaction::UnverifiedTransaction; use ethcore::transaction::{Action, UnverifiedTransaction};
use ethcore::receipt::Receipt; use ethcore::receipt::Receipt;
use io::TimerToken; use io::TimerToken;
@ -73,7 +73,7 @@ pub const PROTOCOL_VERSIONS: &'static [u8] = &[1];
pub const MAX_PROTOCOL_VERSION: u8 = 1; pub const MAX_PROTOCOL_VERSION: u8 = 1;
/// Packet count for LES. /// Packet count for LES.
pub const PACKET_COUNT: u8 = 15; pub const PACKET_COUNT: u8 = 17;
// packet ID definitions. // packet ID definitions.
mod packet { mod packet {
@ -109,6 +109,10 @@ mod packet {
// request and response for header proofs in a CHT. // request and response for header proofs in a CHT.
pub const GET_HEADER_PROOFS: u8 = 0x0d; pub const GET_HEADER_PROOFS: u8 = 0x0d;
pub const HEADER_PROOFS: u8 = 0x0e; pub const HEADER_PROOFS: u8 = 0x0e;
// request and response for transaction proof.
pub const GET_TRANSACTION_PROOF: u8 = 0x0f;
pub const TRANSACTION_PROOF: u8 = 0x10;
} }
// timeouts for different kinds of requests. all values are in milliseconds. // timeouts for different kinds of requests. all values are in milliseconds.
@ -121,6 +125,7 @@ mod timeout {
pub const PROOFS: i64 = 4000; pub const PROOFS: i64 = 4000;
pub const CONTRACT_CODES: i64 = 5000; pub const CONTRACT_CODES: i64 = 5000;
pub const HEADER_PROOFS: i64 = 3500; pub const HEADER_PROOFS: i64 = 3500;
pub const TRANSACTION_PROOF: i64 = 5000;
} }
/// A request id. /// A request id.
@ -370,6 +375,7 @@ impl LightProtocol {
request::Kind::StateProofs => packet::GET_PROOFS, request::Kind::StateProofs => packet::GET_PROOFS,
request::Kind::Codes => packet::GET_CONTRACT_CODES, request::Kind::Codes => packet::GET_CONTRACT_CODES,
request::Kind::HeaderProofs => packet::GET_HEADER_PROOFS, request::Kind::HeaderProofs => packet::GET_HEADER_PROOFS,
request::Kind::TransactionProof => packet::GET_TRANSACTION_PROOF,
}; };
io.send(*peer_id, packet_id, packet_data); io.send(*peer_id, packet_id, packet_data);
@ -1320,6 +1326,25 @@ fn encode_request(req: &Request, req_id: usize) -> Vec<u8> {
.append(&proof_req.from_level); .append(&proof_req.from_level);
} }
stream.out()
}
Request::TransactionProof(ref request) => {
let mut stream = RlpStream::new_list(2);
stream.append(&req_id).begin_list(7)
.append(&request.at)
.append(&request.from);
match request.action {
Action::Create => stream.append_empty_data(),
Action::Call(ref to) => stream.append(to),
};
stream
.append(&request.gas)
.append(&request.gas_price)
.append(&request.value)
.append(&request.data);
stream.out() stream.out()
} }
} }

View File

@ -81,12 +81,13 @@ impl Credits {
/// A cost table, mapping requests to base and per-request costs. /// A cost table, mapping requests to base and per-request costs.
#[derive(Debug, Clone, PartialEq, Eq)] #[derive(Debug, Clone, PartialEq, Eq)]
pub struct CostTable { pub struct CostTable {
headers: Cost, headers: Cost, // cost per header
bodies: Cost, bodies: Cost,
receipts: Cost, receipts: Cost,
state_proofs: Cost, state_proofs: Cost,
contract_codes: Cost, contract_codes: Cost,
header_proofs: Cost, header_proofs: Cost,
transaction_proof: Cost, // cost per gas.
} }
impl Default for CostTable { impl Default for CostTable {
@ -99,6 +100,7 @@ impl Default for CostTable {
state_proofs: Cost(250000.into(), 25000.into()), state_proofs: Cost(250000.into(), 25000.into()),
contract_codes: Cost(200000.into(), 20000.into()), contract_codes: Cost(200000.into(), 20000.into()),
header_proofs: Cost(150000.into(), 15000.into()), header_proofs: Cost(150000.into(), 15000.into()),
transaction_proof: Cost(100000.into(), 2.into()),
} }
} }
} }
@ -133,6 +135,7 @@ impl RlpDecodable for CostTable {
let mut state_proofs = None; let mut state_proofs = None;
let mut contract_codes = None; let mut contract_codes = None;
let mut header_proofs = None; let mut header_proofs = None;
let mut transaction_proof = None;
for row in rlp.iter() { for row in rlp.iter() {
let msg_id: u8 = row.val_at(0)?; let msg_id: u8 = row.val_at(0)?;
@ -150,6 +153,7 @@ impl RlpDecodable for CostTable {
packet::GET_PROOFS => state_proofs = Some(cost), packet::GET_PROOFS => state_proofs = Some(cost),
packet::GET_CONTRACT_CODES => contract_codes = Some(cost), packet::GET_CONTRACT_CODES => contract_codes = Some(cost),
packet::GET_HEADER_PROOFS => header_proofs = Some(cost), packet::GET_HEADER_PROOFS => header_proofs = Some(cost),
packet::GET_TRANSACTION_PROOF => transaction_proof = Some(cost),
_ => return Err(DecoderError::Custom("Unrecognized message in cost table")), _ => return Err(DecoderError::Custom("Unrecognized message in cost table")),
} }
} }
@ -161,6 +165,7 @@ impl RlpDecodable for CostTable {
state_proofs: state_proofs.ok_or(DecoderError::Custom("No proofs cost specified"))?, state_proofs: state_proofs.ok_or(DecoderError::Custom("No proofs cost specified"))?,
contract_codes: contract_codes.ok_or(DecoderError::Custom("No contract codes specified"))?, contract_codes: contract_codes.ok_or(DecoderError::Custom("No contract codes specified"))?,
header_proofs: header_proofs.ok_or(DecoderError::Custom("No header proofs cost specified"))?, header_proofs: header_proofs.ok_or(DecoderError::Custom("No header proofs cost specified"))?,
transaction_proof: transaction_proof.ok_or(DecoderError::Custom("No transaction proof gas cost specified"))?,
}) })
} }
} }
@ -197,6 +202,7 @@ impl FlowParams {
state_proofs: free_cost.clone(), state_proofs: free_cost.clone(),
contract_codes: free_cost.clone(), contract_codes: free_cost.clone(),
header_proofs: free_cost.clone(), header_proofs: free_cost.clone(),
transaction_proof: free_cost,
} }
} }
} }
@ -220,6 +226,7 @@ impl FlowParams {
request::Kind::StateProofs => &self.costs.state_proofs, request::Kind::StateProofs => &self.costs.state_proofs,
request::Kind::Codes => &self.costs.contract_codes, request::Kind::Codes => &self.costs.contract_codes,
request::Kind::HeaderProofs => &self.costs.header_proofs, request::Kind::HeaderProofs => &self.costs.header_proofs,
request::Kind::TransactionProof => &self.costs.transaction_proof,
}; };
let amount: U256 = amount.into(); let amount: U256 = amount.into();
@ -241,6 +248,7 @@ impl FlowParams {
request::Kind::StateProofs => &self.costs.state_proofs, request::Kind::StateProofs => &self.costs.state_proofs,
request::Kind::Codes => &self.costs.contract_codes, request::Kind::Codes => &self.costs.contract_codes,
request::Kind::HeaderProofs => &self.costs.header_proofs, request::Kind::HeaderProofs => &self.costs.header_proofs,
request::Kind::TransactionProof => &self.costs.transaction_proof,
}; };
let start = credits.current(); let start = credits.current();

View File

@ -101,6 +101,7 @@ impl RequestSet {
request::Kind::StateProofs => timeout::PROOFS, request::Kind::StateProofs => timeout::PROOFS,
request::Kind::Codes => timeout::CONTRACT_CODES, request::Kind::Codes => timeout::CONTRACT_CODES,
request::Kind::HeaderProofs => timeout::HEADER_PROOFS, request::Kind::HeaderProofs => timeout::HEADER_PROOFS,
request::Kind::TransactionProof => timeout::TRANSACTION_PROOF,
}; };
base + Duration::milliseconds(kind_timeout) <= now base + Duration::milliseconds(kind_timeout) <= now

View File

@ -24,7 +24,7 @@ use ethcore::client::{BlockChainClient, ProvingBlockChainClient};
use ethcore::transaction::PendingTransaction; use ethcore::transaction::PendingTransaction;
use ethcore::ids::BlockId; use ethcore::ids::BlockId;
use ethcore::encoded; use ethcore::encoded;
use util::{Bytes, RwLock, H256}; use util::{Bytes, DBValue, RwLock, H256};
use cht::{self, BlockInfo}; use cht::{self, BlockInfo};
use client::{LightChainClient, AsLightClient}; use client::{LightChainClient, AsLightClient};
@ -193,6 +193,10 @@ pub trait Provider: Send + Sync {
/// Provide pending transactions. /// Provide pending transactions.
fn ready_transactions(&self) -> Vec<PendingTransaction>; fn ready_transactions(&self) -> Vec<PendingTransaction>;
/// Provide a proof-of-execution for the given transaction proof request.
/// Returns a vector of all state items necessary to execute the transaction.
fn transaction_proof(&self, req: request::TransactionProof) -> Option<Vec<DBValue>>;
} }
// Implementation of a light client data provider for a client. // Implementation of a light client data provider for a client.
@ -283,6 +287,26 @@ impl<T: ProvingBlockChainClient + ?Sized> Provider for T {
} }
} }
fn transaction_proof(&self, req: request::TransactionProof) -> Option<Vec<DBValue>> {
use ethcore::transaction::Transaction;
let id = BlockId::Hash(req.at);
let nonce = match self.nonce(&req.from, id.clone()) {
Some(nonce) => nonce,
None => return None,
};
let transaction = Transaction {
nonce: nonce,
gas: req.gas,
gas_price: req.gas_price,
action: req.action,
value: req.value,
data: req.data,
}.fake_sign(req.from);
self.prove_transaction(transaction, id)
}
fn ready_transactions(&self) -> Vec<PendingTransaction> { fn ready_transactions(&self) -> Vec<PendingTransaction> {
BlockChainClient::ready_transactions(self) BlockChainClient::ready_transactions(self)
} }
@ -343,6 +367,10 @@ impl<L: AsLightClient + Send + Sync> Provider for LightProvider<L> {
None None
} }
fn transaction_proof(&self, req: request::TransactionProof) -> Option<Vec<DBValue>> {
None
}
fn ready_transactions(&self) -> Vec<PendingTransaction> { fn ready_transactions(&self) -> Vec<PendingTransaction> {
let chain_info = self.chain_info(); let chain_info = self.chain_info();
self.txqueue.read().ready_transactions(chain_info.best_block_number, chain_info.best_block_timestamp) self.txqueue.read().ready_transactions(chain_info.best_block_number, chain_info.best_block_timestamp)

View File

@ -16,7 +16,8 @@
//! LES request types. //! LES request types.
use util::H256; use ethcore::transaction::Action;
use util::{Address, H256, U256, Uint};
/// Either a hash or a number. /// Either a hash or a number.
#[derive(Debug, Clone, PartialEq, Eq)] #[derive(Debug, Clone, PartialEq, Eq)]
@ -134,6 +135,26 @@ pub struct HeaderProofs {
pub requests: Vec<HeaderProof>, pub requests: Vec<HeaderProof>,
} }
/// A request for proof of (simulated) transaction execution.
#[derive(Debug, Clone, PartialEq, Eq)]
#[cfg_attr(feature = "ipc", binary)]
pub struct TransactionProof {
/// Block hash to request for.
pub at: H256,
/// Address to treat as the caller.
pub from: Address,
/// Action to take: either a call or a create.
pub action: Action,
/// Amount of gas to request proof-of-execution for.
pub gas: U256,
/// Price for each gas.
pub gas_price: U256,
/// Value to simulate sending.
pub value: U256,
/// Transaction data.
pub data: Vec<u8>,
}
/// Kinds of requests. /// Kinds of requests.
#[derive(Debug, Clone, Copy, PartialEq, Eq)] #[derive(Debug, Clone, Copy, PartialEq, Eq)]
#[cfg_attr(feature = "ipc", binary)] #[cfg_attr(feature = "ipc", binary)]
@ -150,6 +171,8 @@ pub enum Kind {
Codes, Codes,
/// Requesting header proofs (from the CHT). /// Requesting header proofs (from the CHT).
HeaderProofs, HeaderProofs,
/// Requesting proof of transaction execution.
TransactionProof,
} }
/// Encompasses all possible types of requests in a single structure. /// Encompasses all possible types of requests in a single structure.
@ -168,6 +191,8 @@ pub enum Request {
Codes(ContractCodes), Codes(ContractCodes),
/// Requesting header proofs. /// Requesting header proofs.
HeaderProofs(HeaderProofs), HeaderProofs(HeaderProofs),
/// Requesting proof of transaction execution.
TransactionProof(TransactionProof),
} }
impl Request { impl Request {
@ -180,10 +205,12 @@ impl Request {
Request::StateProofs(_) => Kind::StateProofs, Request::StateProofs(_) => Kind::StateProofs,
Request::Codes(_) => Kind::Codes, Request::Codes(_) => Kind::Codes,
Request::HeaderProofs(_) => Kind::HeaderProofs, Request::HeaderProofs(_) => Kind::HeaderProofs,
Request::TransactionProof(_) => Kind::TransactionProof,
} }
} }
/// Get the amount of requests being made. /// Get the amount of requests being made.
/// In the case of `TransactionProof`, this is the amount of gas being requested.
pub fn amount(&self) -> usize { pub fn amount(&self) -> usize {
match *self { match *self {
Request::Headers(ref req) => req.max, Request::Headers(ref req) => req.max,
@ -192,6 +219,10 @@ impl Request {
Request::StateProofs(ref req) => req.requests.len(), Request::StateProofs(ref req) => req.requests.len(),
Request::Codes(ref req) => req.code_requests.len(), Request::Codes(ref req) => req.code_requests.len(),
Request::HeaderProofs(ref req) => req.requests.len(), Request::HeaderProofs(ref req) => req.requests.len(),
Request::TransactionProof(ref req) => match req.gas > usize::max_value().into() {
true => usize::max_value(),
false => req.gas.low_u64() as usize,
}
} }
} }
} }

View File

@ -24,7 +24,7 @@ use time::precise_time_ns;
// util // util
use util::{Bytes, PerfTimer, Itertools, Mutex, RwLock, MutexGuard, Hashable}; use util::{Bytes, PerfTimer, Itertools, Mutex, RwLock, MutexGuard, Hashable};
use util::{journaldb, TrieFactory, Trie}; use util::{journaldb, DBValue, TrieFactory, Trie};
use util::{U256, H256, Address, H2048, Uint, FixedHash}; use util::{U256, H256, Address, H2048, Uint, FixedHash};
use util::trie::TrieSpec; use util::trie::TrieSpec;
use util::kvdb::*; use util::kvdb::*;
@ -34,7 +34,7 @@ use io::*;
use views::BlockView; use views::BlockView;
use error::{ImportError, ExecutionError, CallError, BlockError, ImportResult, Error as EthcoreError}; use error::{ImportError, ExecutionError, CallError, BlockError, ImportResult, Error as EthcoreError};
use header::BlockNumber; use header::BlockNumber;
use state::{State, CleanupMode}; use state::{self, State, CleanupMode};
use spec::Spec; use spec::Spec;
use basic_types::Seal; use basic_types::Seal;
use engines::Engine; use engines::Engine;
@ -309,17 +309,23 @@ impl Client {
/// The env info as of the best block. /// The env info as of the best block.
fn latest_env_info(&self) -> EnvInfo { fn latest_env_info(&self) -> EnvInfo {
let header = self.best_block_header(); self.env_info(BlockId::Latest).expect("Best block header always stored; qed")
}
EnvInfo { /// The env info as of a given block.
number: header.number(), /// returns `None` if the block unknown.
author: header.author(), fn env_info(&self, id: BlockId) -> Option<EnvInfo> {
timestamp: header.timestamp(), self.block_header(id).map(|header| {
difficulty: header.difficulty(), EnvInfo {
last_hashes: self.build_last_hashes(header.hash()), number: header.number(),
gas_used: U256::default(), author: header.author(),
gas_limit: header.gas_limit(), timestamp: header.timestamp(),
} difficulty: header.difficulty(),
last_hashes: self.build_last_hashes(header.parent_hash()),
gas_used: U256::default(),
gas_limit: header.gas_limit(),
}
})
} }
fn build_last_hashes(&self, parent_hash: H256) -> Arc<LastHashes> { fn build_last_hashes(&self, parent_hash: H256) -> Arc<LastHashes> {
@ -874,17 +880,8 @@ impl snapshot::DatabaseRestore for Client {
impl BlockChainClient for Client { impl BlockChainClient for Client {
fn call(&self, t: &SignedTransaction, block: BlockId, analytics: CallAnalytics) -> Result<Executed, CallError> { fn call(&self, t: &SignedTransaction, block: BlockId, analytics: CallAnalytics) -> Result<Executed, CallError> {
let header = self.block_header(block).ok_or(CallError::StatePruned)?; let env_info = self.env_info(block).ok_or(CallError::StatePruned)?;
let last_hashes = self.build_last_hashes(header.parent_hash());
let env_info = EnvInfo {
number: header.number(),
author: header.author(),
timestamp: header.timestamp(),
difficulty: header.difficulty(),
last_hashes: last_hashes,
gas_used: U256::zero(),
gas_limit: U256::max_value(),
};
// that's just a copy of the state. // that's just a copy of the state.
let mut state = self.state_at(block).ok_or(CallError::StatePruned)?; let mut state = self.state_at(block).ok_or(CallError::StatePruned)?;
let original_state = if analytics.state_diffing { Some(state.clone()) } else { None }; let original_state = if analytics.state_diffing { Some(state.clone()) } else { None };
@ -910,17 +907,13 @@ impl BlockChainClient for Client {
fn estimate_gas(&self, t: &SignedTransaction, block: BlockId) -> Result<U256, CallError> { fn estimate_gas(&self, t: &SignedTransaction, block: BlockId) -> Result<U256, CallError> {
const UPPER_CEILING: u64 = 1_000_000_000_000u64; const UPPER_CEILING: u64 = 1_000_000_000_000u64;
let header = self.block_header(block).ok_or(CallError::StatePruned)?; let (mut upper, env_info) = {
let last_hashes = self.build_last_hashes(header.parent_hash()); let mut env_info = self.env_info(block).ok_or(CallError::StatePruned)?;
let env_info = EnvInfo { let initial_upper = env_info.gas_limit;
number: header.number(), env_info.gas_limit = UPPER_CEILING.into();
author: header.author(), (initial_upper, env_info)
timestamp: header.timestamp(),
difficulty: header.difficulty(),
last_hashes: last_hashes,
gas_used: U256::zero(),
gas_limit: UPPER_CEILING.into(),
}; };
// that's just a copy of the state. // that's just a copy of the state.
let original_state = self.state_at(block).ok_or(CallError::StatePruned)?; let original_state = self.state_at(block).ok_or(CallError::StatePruned)?;
let sender = t.sender(); let sender = t.sender();
@ -946,7 +939,6 @@ impl BlockChainClient for Client {
.unwrap_or(false)) .unwrap_or(false))
}; };
let mut upper = header.gas_limit();
if !cond(upper)? { if !cond(upper)? {
// impossible at block gas limit - try `UPPER_CEILING` instead. // impossible at block gas limit - try `UPPER_CEILING` instead.
// TODO: consider raising limit by powers of two. // TODO: consider raising limit by powers of two.
@ -989,7 +981,7 @@ impl BlockChainClient for Client {
fn replay(&self, id: TransactionId, analytics: CallAnalytics) -> Result<Executed, CallError> { fn replay(&self, id: TransactionId, analytics: CallAnalytics) -> Result<Executed, CallError> {
let address = self.transaction_address(id).ok_or(CallError::TransactionNotFound)?; let address = self.transaction_address(id).ok_or(CallError::TransactionNotFound)?;
let header = self.block_header(BlockId::Hash(address.block_hash)).ok_or(CallError::StatePruned)?; let mut env_info = self.env_info(BlockId::Hash(address.block_hash)).ok_or(CallError::StatePruned)?;
let body = self.block_body(BlockId::Hash(address.block_hash)).ok_or(CallError::StatePruned)?; let body = self.block_body(BlockId::Hash(address.block_hash)).ok_or(CallError::StatePruned)?;
let mut state = self.state_at_beginning(BlockId::Hash(address.block_hash)).ok_or(CallError::StatePruned)?; let mut state = self.state_at_beginning(BlockId::Hash(address.block_hash)).ok_or(CallError::StatePruned)?;
let mut txs = body.transactions(); let mut txs = body.transactions();
@ -999,16 +991,6 @@ impl BlockChainClient for Client {
} }
let options = TransactOptions { tracing: analytics.transaction_tracing, vm_tracing: analytics.vm_tracing, check_nonce: false }; let options = TransactOptions { tracing: analytics.transaction_tracing, vm_tracing: analytics.vm_tracing, check_nonce: false };
let last_hashes = self.build_last_hashes(header.hash());
let mut env_info = EnvInfo {
number: header.number(),
author: header.author(),
timestamp: header.timestamp(),
difficulty: header.difficulty(),
last_hashes: last_hashes,
gas_used: U256::default(),
gas_limit: header.gas_limit(),
};
const PROOF: &'static str = "Transactions fetched from blockchain; blockchain transactions are valid; qed"; const PROOF: &'static str = "Transactions fetched from blockchain; blockchain transactions are valid; qed";
let rest = txs.split_off(address.index); let rest = txs.split_off(address.index);
for t in txs { for t in txs {
@ -1620,6 +1602,26 @@ impl ::client::ProvingBlockChainClient for Client {
.and_then(|x| x) .and_then(|x| x)
.unwrap_or_else(Vec::new) .unwrap_or_else(Vec::new)
} }
fn prove_transaction(&self, transaction: SignedTransaction, id: BlockId) -> Option<Vec<DBValue>> {
let (state, env_info) = match (self.state_at(id), self.env_info(id)) {
(Some(s), Some(e)) => (s, e),
_ => return None,
};
let mut jdb = self.state_db.lock().journal_db().boxed_clone();
let backend = state::backend::Proving::new(jdb.as_hashdb_mut());
let mut state = state.replace_backend(backend);
let options = TransactOptions { tracing: false, vm_tracing: false, check_nonce: false };
let res = Executive::new(&mut state, &env_info, &*self.engine, &self.factories.vm).transact(&transaction, options);
match res {
Err(ExecutionError::Internal(_)) => return None,
_ => return Some(state.drop().1.extract_proof()),
}
}
} }
impl Drop for Client { impl Drop for Client {

View File

@ -765,6 +765,10 @@ impl ProvingBlockChainClient for TestBlockChainClient {
fn code_by_hash(&self, _: H256, _: BlockId) -> Bytes { fn code_by_hash(&self, _: H256, _: BlockId) -> Bytes {
Vec::new() Vec::new()
} }
fn prove_transaction(&self, _: SignedTransaction, _: BlockId) -> Option<Vec<DBValue>> {
None
}
} }
impl EngineClient for TestBlockChainClient { impl EngineClient for TestBlockChainClient {

View File

@ -16,6 +16,7 @@
use std::collections::BTreeMap; use std::collections::BTreeMap;
use util::{U256, Address, H256, H2048, Bytes, Itertools}; use util::{U256, Address, H256, H2048, Bytes, Itertools};
use util::hashdb::DBValue;
use util::stats::Histogram; use util::stats::Histogram;
use blockchain::TreeRoute; use blockchain::TreeRoute;
use verification::queue::QueueInfo as BlockQueueInfo; use verification::queue::QueueInfo as BlockQueueInfo;
@ -336,4 +337,7 @@ pub trait ProvingBlockChainClient: BlockChainClient {
/// Get code by address hash. /// Get code by address hash.
fn code_by_hash(&self, account_key: H256, id: BlockId) -> Bytes; fn code_by_hash(&self, account_key: H256, id: BlockId) -> Bytes;
/// Prove execution of a transaction at the given block.
fn prove_transaction(&self, transaction: SignedTransaction, id: BlockId) -> Option<Vec<DBValue>>;
} }

View File

@ -98,7 +98,6 @@ impl<T: AsHashDB + Send> Backend for NoCache<T> {
/// See module docs for more details. /// See module docs for more details.
/// ///
/// This doesn't cache anything or rely on the canonical state caches. /// This doesn't cache anything or rely on the canonical state caches.
#[derive(Debug, Clone, PartialEq)]
pub struct Proving<H: AsHashDB> { pub struct Proving<H: AsHashDB> {
base: H, // state we're proving values from. base: H, // state we're proving values from.
changed: MemoryDB, // changed state via insertions. changed: MemoryDB, // changed state via insertions.
@ -107,8 +106,9 @@ pub struct Proving<H: AsHashDB> {
impl<H: AsHashDB + Send + Sync> HashDB for Proving<H> { impl<H: AsHashDB + Send + Sync> HashDB for Proving<H> {
fn keys(&self) -> HashMap<H256, i32> { fn keys(&self) -> HashMap<H256, i32> {
self.base.as_hashdb().keys() let mut keys = self.base.as_hashdb().keys();
.extend(self.changed.keys()) keys.extend(self.changed.keys());
keys
} }
fn get(&self, key: &H256) -> Option<DBValue> { fn get(&self, key: &H256) -> Option<DBValue> {
@ -141,7 +141,7 @@ impl<H: AsHashDB + Send + Sync> HashDB for Proving<H> {
} }
} }
impl<H: AsHashDB + Send> Backend for Proving<H> { impl<H: AsHashDB + Send + Sync> Backend for Proving<H> {
fn as_hashdb(&self) -> &HashDB { fn as_hashdb(&self) -> &HashDB {
self self
} }
@ -183,3 +183,13 @@ impl<H: AsHashDB> Proving<H> {
self.proof.into_inner().into_iter().collect() self.proof.into_inner().into_iter().collect()
} }
} }
impl<H: AsHashDB + Clone> Clone for Proving<H> {
fn clone(&self) -> Self {
Proving {
base: self.base.clone(),
changed: self.changed.clone(),
proof: Mutex::new(self.proof.lock().clone()),
}
}
}

View File

@ -264,6 +264,19 @@ impl<B: Backend> State<B> {
Ok(state) Ok(state)
} }
/// Swap the current backend for another.
// TODO: [rob] find a less hacky way to avoid duplication of `Client::state_at`.
pub fn replace_backend<T: Backend>(self, backend: T) -> State<T> {
State {
db: backend,
root: self.root,
cache: self.cache,
checkpoints: self.checkpoints,
account_start_nonce: self.account_start_nonce,
factories: self.factories,
}
}
/// Create a recoverable checkpoint of this state. /// Create a recoverable checkpoint of this state.
pub fn checkpoint(&mut self) { pub fn checkpoint(&mut self) {
self.checkpoints.get_mut().push(HashMap::new()); self.checkpoints.get_mut().push(HashMap::new());

View File

@ -125,3 +125,13 @@ impl<T: HashDB> AsHashDB for T {
self self
} }
} }
impl<'a> AsHashDB for &'a mut HashDB {
fn as_hashdb(&self) -> &HashDB {
&**self
}
fn as_hashdb_mut(&mut self) -> &mut HashDB {
&mut **self
}
}