RpcBlockchainStateProvider

Struct RpcBlockchainStateProvider 

Source
pub struct RpcBlockchainStateProvider<P, Node, N = AnyNetwork>
where Node: NodeTypes,
{ /* private fields */ }
Expand description

RPC-based state provider implementation that fetches blockchain state via remote RPC calls.

This is the state provider counterpart to RpcBlockchainProvider, handling state queries at specific block heights via RPC instead of local database access.

Implementations§

Source§

impl<P: Clone, Node: NodeTypes, N> RpcBlockchainStateProvider<P, Node, N>

Source

pub fn new( provider: P, block_id: BlockId, _primitives: PhantomData<Node>, ) -> Self

Creates a new state provider for the given block

Source

pub fn with_chain_spec( provider: P, block_id: BlockId, chain_spec: Arc<Node::ChainSpec>, ) -> Self

Creates a new state provider with a cached chain spec

Source

pub const fn with_compute_state_root(self, is_enable: bool) -> Self

Helper function to enable state root calculation

If enabled, the node will compute the state root and updates. When disabled, it will return zero for state root and no updates.

Source

pub const fn with_reth_rpc_support(self, is_enable: bool) -> Self

Sets whether to use Reth-specific RPC methods for better performance

If enabled, the node will use Reth’s RPC methods (debug_codeByHash and eth_getAccountInfo) to speed up account information retrieval. When disabled, it will use multiple standard RPC calls to get account information.

Trait Implementations§

Source§

impl<P, Node, N> AccountReader for RpcBlockchainStateProvider<P, Node, N>
where P: Provider<N> + Clone + 'static, N: Network, Node: NodeTypes,

Source§

fn basic_account( &self, address: &Address, ) -> Result<Option<Account>, ProviderError>

Get basic account information. Read more
Source§

impl<P, Node, N> BlockBodyIndicesProvider for RpcBlockchainStateProvider<P, Node, N>
where P: Provider<N> + Clone + 'static, N: Network, Node: NodeTypes,

Source§

fn block_body_indices( &self, _num: u64, ) -> Result<Option<StoredBlockBodyIndices>, ProviderError>

Returns the block body indices with matching number from database. Read more
Source§

fn block_body_indices_range( &self, _range: RangeInclusive<u64>, ) -> Result<Vec<StoredBlockBodyIndices>, ProviderError>

Returns the block body indices within the requested range matching number from storage.
Source§

impl<P, Node, N> BlockHashReader for RpcBlockchainStateProvider<P, Node, N>
where P: Provider<N> + Clone + 'static, N: Network, Node: NodeTypes,

Source§

fn block_hash(&self, number: u64) -> Result<Option<B256>, ProviderError>

Get the hash of the block with the given number. Returns None if no block with this number exists.
Source§

fn canonical_hashes_range( &self, _start: BlockNumber, _end: BlockNumber, ) -> Result<Vec<B256>, ProviderError>

Get headers in range of block hashes or numbers Read more
§

fn convert_block_hash( &self, hash_or_number: HashOrNumber, ) -> Result<Option<FixedBytes<32>>, ProviderError>

Get the hash of the block with the given number. Returns None if no block with this number exists.
Source§

impl<P, Node, N> BlockIdReader for RpcBlockchainStateProvider<P, Node, N>
where P: Provider<N> + Clone + 'static, N: Network, Node: NodeTypes,

Source§

fn block_number_for_id( &self, _block_id: BlockId, ) -> Result<Option<BlockNumber>, ProviderError>

Get the number of the block by matching the given id.
Source§

fn pending_block_num_hash(&self) -> Result<Option<BlockNumHash>, ProviderError>

Get the current pending block number and hash.
Source§

fn safe_block_num_hash(&self) -> Result<Option<BlockNumHash>, ProviderError>

Get the current safe block number and hash.
Source§

fn finalized_block_num_hash( &self, ) -> Result<Option<BlockNumHash>, ProviderError>

Get the current finalized block number and hash.
§

fn convert_block_number( &self, num: BlockNumberOrTag, ) -> Result<Option<u64>, ProviderError>

Converts the BlockNumberOrTag variants to a block number.
§

fn block_hash_for_id( &self, block_id: BlockId, ) -> Result<Option<FixedBytes<32>>, ProviderError>

Get the hash of the block by matching the given id.
§

fn safe_block_number(&self) -> Result<Option<u64>, ProviderError>

Get the safe block number.
§

fn finalized_block_number(&self) -> Result<Option<u64>, ProviderError>

Get the finalized block number.
§

fn safe_block_hash(&self) -> Result<Option<FixedBytes<32>>, ProviderError>

Get the safe block hash.
§

fn finalized_block_hash(&self) -> Result<Option<FixedBytes<32>>, ProviderError>

Get the finalized block hash.
Source§

impl<P, Node, N> BlockNumReader for RpcBlockchainStateProvider<P, Node, N>
where P: Provider<N> + Clone + 'static, N: Network, Node: NodeTypes,

Source§

fn chain_info(&self) -> Result<ChainInfo, ProviderError>

Returns the current info for the chain.
Source§

fn best_block_number(&self) -> Result<BlockNumber, ProviderError>

Returns the best block number in the chain.
Source§

fn last_block_number(&self) -> Result<BlockNumber, ProviderError>

Returns the last block number associated with the last canonical header in the database.
Source§

fn block_number(&self, hash: B256) -> Result<Option<BlockNumber>, ProviderError>

Gets the BlockNumber for the given hash. Returns None if no block with this hash exists.
§

fn earliest_block_number(&self) -> Result<u64, ProviderError>

Returns earliest block number to keep track of the expired block range.
§

fn convert_hash_or_number( &self, id: HashOrNumber, ) -> Result<Option<u64>, ProviderError>

Gets the block number for the given BlockHashOrNumber. Returns None if no block with this hash exists. If the BlockHashOrNumber is a Number, it is returned as is.
§

fn convert_number( &self, id: HashOrNumber, ) -> Result<Option<FixedBytes<32>>, ProviderError>

Gets the block hash for the given BlockHashOrNumber. Returns None if no block with this number exists. If the BlockHashOrNumber is a Hash, it is returned as is.
Source§

impl<P, Node, N> BlockReader for RpcBlockchainStateProvider<P, Node, N>
where P: Provider<N> + Clone + 'static, N: Network, Node: NodeTypes,

Source§

type Block = <<Node as NodeTypes>::Primitives as NodePrimitives>::Block

The block type this provider reads.
Source§

fn find_block_by_hash( &self, _hash: B256, _source: BlockSource, ) -> Result<Option<Self::Block>, ProviderError>

Tries to find in the given block source. Read more
Source§

fn block( &self, _id: BlockHashOrNumber, ) -> Result<Option<Self::Block>, ProviderError>

Returns the block with given id from the database. Read more
Source§

fn pending_block( &self, ) -> Result<Option<RecoveredBlock<Self::Block>>, ProviderError>

Returns the pending block if available Read more
Source§

fn pending_block_and_receipts( &self, ) -> Result<Option<(RecoveredBlock<Self::Block>, Vec<Self::Receipt>)>, ProviderError>

Returns the pending block and receipts if available.
Source§

fn recovered_block( &self, _id: BlockHashOrNumber, _transaction_kind: TransactionVariant, ) -> Result<Option<RecoveredBlock<Self::Block>>, ProviderError>

Returns the block with senders with matching number or hash from database. Read more
Source§

fn sealed_block_with_senders( &self, _id: BlockHashOrNumber, _transaction_kind: TransactionVariant, ) -> Result<Option<RecoveredBlock<BlockTy<Node>>>, ProviderError>

Returns the sealed block with senders with matching number or hash from database. Read more
Source§

fn block_range( &self, _range: RangeInclusive<BlockNumber>, ) -> Result<Vec<Self::Block>, ProviderError>

Returns all blocks in the given inclusive range. Read more
Source§

fn block_with_senders_range( &self, _range: RangeInclusive<BlockNumber>, ) -> Result<Vec<RecoveredBlock<BlockTy<Node>>>, ProviderError>

Returns a range of blocks from the database, along with the senders of each transaction in the blocks.
Source§

fn recovered_block_range( &self, _range: RangeInclusive<BlockNumber>, ) -> Result<Vec<RecoveredBlock<Self::Block>>, ProviderError>

Returns a range of sealed blocks from the database, along with the senders of each transaction in the blocks.
§

fn block_by_hash( &self, hash: FixedBytes<32>, ) -> Result<Option<Self::Block>, ProviderError>

Returns the block with matching hash from the database. Read more
§

fn block_by_number( &self, num: u64, ) -> Result<Option<Self::Block>, ProviderError>

Returns the block with matching number from database. Read more
Source§

impl<P, Node, N> BytecodeReader for RpcBlockchainStateProvider<P, Node, N>
where P: Provider<N> + Clone + 'static, N: Network, Node: NodeTypes,

Source§

fn bytecode_by_hash( &self, code_hash: &B256, ) -> Result<Option<Bytecode>, ProviderError>

Get account code by its hash
Source§

impl<P, Node, N> ChainSpecProvider for RpcBlockchainStateProvider<P, Node, N>
where P: Send + Sync + Debug, N: Send + Sync, Node: NodeTypes, Node::ChainSpec: Default,

Source§

type ChainSpec = <Node as NodeTypes>::ChainSpec

The chain spec type.
Source§

fn chain_spec(&self) -> Arc<Self::ChainSpec>

Get an Arc to the chainspec.
Source§

impl<P, Node, N> ChainStateBlockReader for RpcBlockchainStateProvider<P, Node, N>
where P: Provider<N> + Clone + 'static, N: Network, Node: NodeTypes,

Source§

fn last_finalized_block_number( &self, ) -> Result<Option<BlockNumber>, ProviderError>

Returns the last finalized block number. Read more
Source§

fn last_safe_block_number(&self) -> Result<Option<BlockNumber>, ProviderError>

Returns the last safe block number. Read more
Source§

impl<P, Node, N> ChainStateBlockWriter for RpcBlockchainStateProvider<P, Node, N>
where P: Provider<N> + Clone + 'static, N: Network, Node: NodeTypes,

Source§

fn save_finalized_block_number( &self, _block_number: BlockNumber, ) -> Result<(), ProviderError>

Saves the given finalized block number in the DB.
Source§

fn save_safe_block_number( &self, _block_number: BlockNumber, ) -> Result<(), ProviderError>

Saves the given safe block number in the DB.
Source§

impl<P, Node, N> ChangeSetReader for RpcBlockchainStateProvider<P, Node, N>
where P: Provider<N> + Clone + 'static, N: Network, Node: NodeTypes,

Source§

fn account_block_changeset( &self, _block_number: BlockNumber, ) -> Result<Vec<AccountBeforeTx>, ProviderError>

Iterate over account changesets and return the account state from before this block.
Source§

impl<P, Node, N> DBProvider for RpcBlockchainStateProvider<P, Node, N>
where P: Provider<N> + Clone + 'static, N: Network, Node: NodeTypes,

Source§

type Tx = TxMock

Underlying database transaction held by the provider.
Source§

fn tx_ref(&self) -> &Self::Tx

Returns a reference to the underlying transaction.
Source§

fn tx_mut(&mut self) -> &mut Self::Tx

Returns a mutable reference to the underlying transaction.
Source§

fn into_tx(self) -> Self::Tx

Consumes the provider and returns the underlying transaction.
Source§

fn prune_modes_ref(&self) -> &PruneModes

Returns a reference to prune modes.
Source§

fn disable_long_read_transaction_safety(self) -> Self

Disables long-lived read transaction safety guarantees for leaks prevention and observability improvements. Read more
§

fn commit(self) -> Result<bool, ProviderError>

Commit database transaction
§

fn table<T>( &self, ) -> Result<Vec<(<T as Table>::Key, <T as Table>::Value)>, DatabaseError>
where T: Table, <T as Table>::Key: Default + Ord,

Return full table as Vec
§

fn get<T>( &self, range: impl RangeBounds<<T as Table>::Key>, ) -> Result<Vec<(<T as Table>::Key, <T as Table>::Value)>, DatabaseError>
where T: Table,

Return a list of entries from the table, based on the given range.
§

fn cursor_read_collect<T>( &self, range: impl RangeBounds<<T as Table>::Key>, ) -> Result<Vec<<T as Table>::Value>, ProviderError>
where T: Table<Key = u64>,

Iterates over read only values in the given table and collects them into a vector. Read more
§

fn cursor_collect<T>( &self, cursor: &mut impl DbCursorRO<T>, range: impl RangeBounds<<T as Table>::Key>, ) -> Result<Vec<<T as Table>::Value>, ProviderError>
where T: Table<Key = u64>,

Iterates over read only values in the given table and collects them into a vector.
§

fn cursor_collect_with_capacity<T>( &self, cursor: &mut impl DbCursorRO<T>, range: impl RangeBounds<<T as Table>::Key>, capacity: usize, ) -> Result<Vec<<T as Table>::Value>, ProviderError>
where T: Table<Key = u64>,

Iterates over read only values in the given table and collects them into a vector with capacity.
§

fn remove<T>( &self, range: impl RangeBounds<<T as Table>::Key>, ) -> Result<usize, DatabaseError>
where T: Table, Self::Tx: DbTxMut,

Remove list of entries from the table. Returns the number of entries removed.
§

fn take<T>( &self, range: impl RangeBounds<<T as Table>::Key>, ) -> Result<Vec<(<T as Table>::Key, <T as Table>::Value)>, DatabaseError>
where T: Table, Self::Tx: DbTxMut,

Return a list of entries from the table, and remove them, based on the given range.
Source§

impl<P: Debug, Node: NodeTypes, N> Debug for RpcBlockchainStateProvider<P, Node, N>

Source§

fn fmt(&self, f: &mut Formatter<'_>) -> Result

Formats the value using the given formatter. Read more
Source§

impl<P, Node, N> HashedPostStateProvider for RpcBlockchainStateProvider<P, Node, N>
where P: Provider<N> + Clone + 'static, N: Network, Node: NodeTypes,

Source§

fn hashed_post_state(&self, _bundle_state: &BundleState) -> HashedPostState

Returns the HashedPostState of the provided [BundleState].
Source§

impl<P, Node, N> HeaderProvider for RpcBlockchainStateProvider<P, Node, N>
where P: Provider<N> + Clone + 'static, N: Network, Node: NodeTypes,

Source§

type Header = <<Node as NodeTypes>::Primitives as NodePrimitives>::BlockHeader

The header type this provider supports.
Source§

fn header( &self, _block_hash: &BlockHash, ) -> Result<Option<Self::Header>, ProviderError>

Get header by block hash
Source§

fn header_by_number( &self, _num: BlockNumber, ) -> Result<Option<Self::Header>, ProviderError>

Get header by block number
Source§

fn header_td(&self, _hash: &BlockHash) -> Result<Option<U256>, ProviderError>

Get total difficulty by block hash.
Source§

fn header_td_by_number( &self, _number: BlockNumber, ) -> Result<Option<U256>, ProviderError>

Get total difficulty by block number.
Source§

fn headers_range( &self, _range: impl RangeBounds<BlockNumber>, ) -> Result<Vec<Self::Header>, ProviderError>

Get headers in range of block numbers
Source§

fn sealed_header( &self, _number: BlockNumber, ) -> Result<Option<SealedHeader<HeaderTy<Node>>>, ProviderError>

Get a single sealed header by block number.
Source§

fn sealed_headers_range( &self, _range: impl RangeBounds<BlockNumber>, ) -> Result<Vec<SealedHeader<HeaderTy<Node>>>, ProviderError>

Get headers in range of block numbers.
Source§

fn sealed_headers_while( &self, _range: impl RangeBounds<BlockNumber>, _predicate: impl FnMut(&SealedHeader<HeaderTy<Node>>) -> bool, ) -> Result<Vec<SealedHeader<HeaderTy<Node>>>, ProviderError>

Get sealed headers while predicate returns true or the range is exhausted.
§

fn is_known(&self, block_hash: &FixedBytes<32>) -> Result<bool, ProviderError>

Check if block is known
§

fn sealed_header_by_hash( &self, block_hash: FixedBytes<32>, ) -> Result<Option<SealedHeader<Self::Header>>, ProviderError>

Retrieves the header sealed by the given block hash.
§

fn header_by_hash_or_number( &self, hash_or_num: HashOrNumber, ) -> Result<Option<Self::Header>, ProviderError>

Get header by block number or hash
Source§

impl<P, Node, N> NodePrimitivesProvider for RpcBlockchainStateProvider<P, Node, N>
where P: Send + Sync + Debug, N: Send + Sync, Node: NodeTypes,

Source§

type Primitives = <Node as NodeTypes>::Primitives

The node primitive types.
Source§

impl<P, Node, N> PruneCheckpointReader for RpcBlockchainStateProvider<P, Node, N>
where P: Provider<N> + Clone + 'static, N: Network, Node: NodeTypes,

Source§

fn get_prune_checkpoint( &self, _segment: PruneSegment, ) -> Result<Option<PruneCheckpoint>, ProviderError>

Fetch the prune checkpoint for the given segment.
Source§

fn get_prune_checkpoints( &self, ) -> Result<Vec<(PruneSegment, PruneCheckpoint)>, ProviderError>

Fetch all the prune checkpoints.
Source§

impl<P, Node, N> ReceiptProvider for RpcBlockchainStateProvider<P, Node, N>
where P: Provider<N> + Clone + 'static, N: Network, Node: NodeTypes,

Source§

type Receipt = <<Node as NodeTypes>::Primitives as NodePrimitives>::Receipt

The receipt type.
Source§

fn receipt(&self, _id: TxNumber) -> Result<Option<Self::Receipt>, ProviderError>

Get receipt by transaction number Read more
Source§

fn receipt_by_hash( &self, _hash: B256, ) -> Result<Option<Self::Receipt>, ProviderError>

Get receipt by transaction hash. Read more
Source§

fn receipts_by_block( &self, _block: BlockHashOrNumber, ) -> Result<Option<Vec<Self::Receipt>>, ProviderError>

Get receipts by block num or hash. Read more
Source§

fn receipts_by_tx_range( &self, _range: impl RangeBounds<TxNumber>, ) -> Result<Vec<Self::Receipt>, ProviderError>

Get receipts by tx range.
Source§

fn receipts_by_block_range( &self, _range: RangeInclusive<BlockNumber>, ) -> Result<Vec<Vec<Self::Receipt>>, ProviderError>

Get receipts by block range. Read more
Source§

impl<P, Node, N> StageCheckpointReader for RpcBlockchainStateProvider<P, Node, N>
where P: Provider<N> + Clone + 'static, N: Network, Node: NodeTypes,

Source§

fn get_stage_checkpoint( &self, _id: StageId, ) -> Result<Option<StageCheckpoint>, ProviderError>

Fetch the checkpoint for the given stage.
Source§

fn get_stage_checkpoint_progress( &self, _id: StageId, ) -> Result<Option<Vec<u8>>, ProviderError>

Get stage checkpoint progress.
Source§

fn get_all_checkpoints( &self, ) -> Result<Vec<(String, StageCheckpoint)>, ProviderError>

Reads all stage checkpoints and returns a list with the name of the stage and the checkpoint data.
Source§

impl<P, Node, N> StateProofProvider for RpcBlockchainStateProvider<P, Node, N>
where P: Provider<N> + Clone + 'static, N: Network, Node: NodeTypes,

Source§

fn proof( &self, _input: TrieInput, _address: Address, _slots: &[B256], ) -> Result<AccountProof, ProviderError>

Get account and storage proofs of target keys in the HashedPostState on top of the current state.
Source§

fn multiproof( &self, _input: TrieInput, _targets: MultiProofTargets, ) -> Result<MultiProof, ProviderError>

Generate [MultiProof] for target hashed account and corresponding hashed storage slot keys.
Source§

fn witness( &self, _input: TrieInput, _target: HashedPostState, ) -> Result<Vec<Bytes>, ProviderError>

Get trie witness for provided state.
Source§

impl<P, Node, N> StateProvider for RpcBlockchainStateProvider<P, Node, N>
where P: Provider<N> + Clone + 'static, N: Network, Node: NodeTypes,

Source§

fn storage( &self, address: Address, storage_key: StorageKey, ) -> Result<Option<U256>, ProviderError>

Get storage of given account.
Source§

fn account_code( &self, addr: &Address, ) -> Result<Option<Bytecode>, ProviderError>

Get account code by its address. Read more
Source§

fn account_balance(&self, addr: &Address) -> Result<Option<U256>, ProviderError>

Get account balance by its address. Read more
Source§

fn account_nonce(&self, addr: &Address) -> Result<Option<u64>, ProviderError>

Get account nonce by its address. Read more
Source§

impl<P, Node, N> StateProviderFactory for RpcBlockchainStateProvider<P, Node, N>
where P: Provider<N> + Clone + 'static + Send + Sync, Node: NodeTypes + 'static, Node::ChainSpec: Send + Sync, N: Network, Self: Clone + 'static,

Source§

fn latest(&self) -> Result<StateProviderBox, ProviderError>

Storage provider for latest block.
Source§

fn state_by_block_id( &self, block_id: BlockId, ) -> Result<StateProviderBox, ProviderError>

Returns a [StateProvider] indexed by the given [BlockId]. Read more
Source§

fn state_by_block_number_or_tag( &self, number_or_tag: BlockNumberOrTag, ) -> Result<StateProviderBox, ProviderError>

Returns a [StateProvider] indexed by the given block number or tag. Read more
Source§

fn history_by_block_number( &self, block_number: BlockNumber, ) -> Result<StateProviderBox, ProviderError>

Returns a historical [StateProvider] indexed by the given historic block number. Read more
Source§

fn history_by_block_hash( &self, block_hash: BlockHash, ) -> Result<StateProviderBox, ProviderError>

Returns a historical [StateProvider] indexed by the given block hash. Read more
Source§

fn state_by_block_hash( &self, block_hash: BlockHash, ) -> Result<StateProviderBox, ProviderError>

Returns any [StateProvider] with matching block hash. Read more
Source§

fn pending(&self) -> Result<StateProviderBox, ProviderError>

Storage provider for pending state. Read more
Source§

fn pending_state_by_hash( &self, _block_hash: B256, ) -> Result<Option<StateProviderBox>, ProviderError>

Storage provider for pending state for the given block hash. Read more
Source§

impl<P, Node, N> StateReader for RpcBlockchainStateProvider<P, Node, N>
where P: Provider<N> + Clone + 'static, N: Network, Node: NodeTypes,

Source§

type Receipt = <<Node as NodeTypes>::Primitives as NodePrimitives>::Receipt

Receipt type in [ExecutionOutcome].
Source§

fn get_state( &self, _block: BlockNumber, ) -> Result<Option<ExecutionOutcome<Self::Receipt>>, ProviderError>

Get the [ExecutionOutcome] for the given block
Source§

impl<P, Node, N> StateRootProvider for RpcBlockchainStateProvider<P, Node, N>
where P: Provider<N> + Clone + 'static, N: Network, Node: NodeTypes,

Source§

fn state_root( &self, hashed_state: HashedPostState, ) -> Result<B256, ProviderError>

Returns the state root of the BundleState on top of the current state. Read more
Source§

fn state_root_from_nodes( &self, _input: TrieInput, ) -> Result<B256, ProviderError>

Returns the state root of the HashedPostState on top of the current state but reuses the intermediate nodes to speed up the computation. It’s up to the caller to construct the prefix sets and inform the provider of the trie paths that have changes.
Source§

fn state_root_with_updates( &self, hashed_state: HashedPostState, ) -> Result<(B256, TrieUpdates), ProviderError>

Returns the state root of the HashedPostState on top of the current state with trie updates to be committed to the database.
Source§

fn state_root_from_nodes_with_updates( &self, _input: TrieInput, ) -> Result<(B256, TrieUpdates), ProviderError>

Returns state root and trie updates. See [StateRootProvider::state_root_from_nodes] for more info.
Source§

impl<P, Node, N> StatsReader for RpcBlockchainStateProvider<P, Node, N>
where P: Provider<N> + Clone + 'static, N: Network, Node: NodeTypes,

Source§

fn count_entries<T: Table>(&self) -> Result<usize, ProviderError>

Fetch the number of entries in the corresponding [Table]. Depending on the provider, it may route to different data sources other than [Table].
Source§

impl<P, Node, N> StorageReader for RpcBlockchainStateProvider<P, Node, N>
where P: Provider<N> + Clone + 'static, N: Network, Node: NodeTypes,

Source§

fn plain_state_storages( &self, addresses_with_keys: impl IntoIterator<Item = (Address, impl IntoIterator<Item = StorageKey>)>, ) -> Result<Vec<(Address, Vec<StorageEntry>)>, ProviderError>

Get plainstate storages for addresses and storage keys.
Source§

fn changed_storages_with_range( &self, _range: RangeInclusive<BlockNumber>, ) -> Result<BTreeMap<Address, BTreeSet<StorageKey>>, ProviderError>

Iterate over storage changesets and return all storage slots that were changed.
Source§

fn changed_storages_and_blocks_with_range( &self, _range: RangeInclusive<BlockNumber>, ) -> Result<BTreeMap<(Address, StorageKey), Vec<u64>>, ProviderError>

Iterate over storage changesets and return all storage slots that were changed alongside each specific set of blocks. Read more
Source§

impl<P, Node, N> StorageRootProvider for RpcBlockchainStateProvider<P, Node, N>
where P: Provider<N> + Clone + 'static, N: Network, Node: NodeTypes,

Source§

fn storage_root( &self, _address: Address, _hashed_storage: HashedStorage, ) -> Result<B256, ProviderError>

Returns the storage root of the HashedStorage for target address on top of the current state.
Source§

fn storage_proof( &self, _address: Address, _slot: B256, _hashed_storage: HashedStorage, ) -> Result<StorageProof, ProviderError>

Returns the storage proof of the HashedStorage for target slot on top of the current state.
Source§

fn storage_multiproof( &self, _address: Address, _slots: &[B256], _hashed_storage: HashedStorage, ) -> Result<StorageMultiProof, ProviderError>

Returns the storage multiproof for target slots.
Source§

impl<P, Node, N> TransactionsProvider for RpcBlockchainStateProvider<P, Node, N>
where P: Provider<N> + Clone + 'static, N: Network, Node: NodeTypes,

Source§

type Transaction = <<Node as NodeTypes>::Primitives as NodePrimitives>::SignedTx

The transaction type this provider reads.
Source§

fn transaction_id( &self, _tx_hash: B256, ) -> Result<Option<TxNumber>, ProviderError>

Get internal transaction identifier by transaction hash. Read more
Source§

fn transaction_by_id( &self, _id: TxNumber, ) -> Result<Option<Self::Transaction>, ProviderError>

Get transaction by id, computes hash every time so more expensive.
Source§

fn transaction_by_id_unhashed( &self, _id: TxNumber, ) -> Result<Option<Self::Transaction>, ProviderError>

Get transaction by id without computing the hash.
Source§

fn transaction_by_hash( &self, _hash: B256, ) -> Result<Option<Self::Transaction>, ProviderError>

Get transaction by transaction hash.
Source§

fn transaction_by_hash_with_meta( &self, _hash: B256, ) -> Result<Option<(Self::Transaction, TransactionMeta)>, ProviderError>

Get transaction by transaction hash and additional metadata of the block the transaction was mined in
Source§

fn transaction_block( &self, _id: TxNumber, ) -> Result<Option<BlockNumber>, ProviderError>

Get transaction block number
Source§

fn transactions_by_block( &self, _block: BlockHashOrNumber, ) -> Result<Option<Vec<Self::Transaction>>, ProviderError>

Get transactions by block id.
Source§

fn transactions_by_block_range( &self, _range: impl RangeBounds<BlockNumber>, ) -> Result<Vec<Vec<Self::Transaction>>, ProviderError>

Get transactions by block range.
Source§

fn transactions_by_tx_range( &self, _range: impl RangeBounds<TxNumber>, ) -> Result<Vec<Self::Transaction>, ProviderError>

Get transactions by tx range.
Source§

fn senders_by_tx_range( &self, _range: impl RangeBounds<TxNumber>, ) -> Result<Vec<Address>, ProviderError>

Get Senders from a tx range.
Source§

fn transaction_sender( &self, _id: TxNumber, ) -> Result<Option<Address>, ProviderError>

Get transaction sender. Read more

Auto Trait Implementations§

§

impl<P, Node, N = AnyNetwork> !Freeze for RpcBlockchainStateProvider<P, Node, N>

§

impl<P, Node, N = AnyNetwork> !RefUnwindSafe for RpcBlockchainStateProvider<P, Node, N>

§

impl<P, Node, N> Send for RpcBlockchainStateProvider<P, Node, N>
where P: Send, N: Send,

§

impl<P, Node, N> Sync for RpcBlockchainStateProvider<P, Node, N>
where P: Sync, N: Sync,

§

impl<P, Node, N> Unpin for RpcBlockchainStateProvider<P, Node, N>
where P: Unpin, N: Unpin,

§

impl<P, Node, N> UnwindSafe for RpcBlockchainStateProvider<P, Node, N>
where P: UnwindSafe, Node: UnwindSafe, N: UnwindSafe, <Node as NodeTypes>::ChainSpec: RefUnwindSafe,

Blanket Implementations§

Source§

impl<T> Any for T
where T: 'static + ?Sized,

Source§

fn type_id(&self) -> TypeId

Gets the TypeId of self. Read more
Source§

impl<T> Borrow<T> for T
where T: ?Sized,

Source§

fn borrow(&self) -> &T

Immutably borrows from an owned value. Read more
Source§

impl<T> BorrowMut<T> for T
where T: ?Sized,

Source§

fn borrow_mut(&mut self) -> &mut T

Mutably borrows from an owned value. Read more
§

impl<T> Conv for T

§

fn conv<T>(self) -> T
where Self: Into<T>,

Converts self into T using Into<T>. Read more
§

impl<T> FmtForward for T

§

fn fmt_binary(self) -> FmtBinary<Self>
where Self: Binary,

Causes self to use its Binary implementation when Debug-formatted.
§

fn fmt_display(self) -> FmtDisplay<Self>
where Self: Display,

Causes self to use its Display implementation when Debug-formatted.
§

fn fmt_lower_exp(self) -> FmtLowerExp<Self>
where Self: LowerExp,

Causes self to use its LowerExp implementation when Debug-formatted.
§

fn fmt_lower_hex(self) -> FmtLowerHex<Self>
where Self: LowerHex,

Causes self to use its LowerHex implementation when Debug-formatted.
§

fn fmt_octal(self) -> FmtOctal<Self>
where Self: Octal,

Causes self to use its Octal implementation when Debug-formatted.
§

fn fmt_pointer(self) -> FmtPointer<Self>
where Self: Pointer,

Causes self to use its Pointer implementation when Debug-formatted.
§

fn fmt_upper_exp(self) -> FmtUpperExp<Self>
where Self: UpperExp,

Causes self to use its UpperExp implementation when Debug-formatted.
§

fn fmt_upper_hex(self) -> FmtUpperHex<Self>
where Self: UpperHex,

Causes self to use its UpperHex implementation when Debug-formatted.
§

fn fmt_list(self) -> FmtList<Self>
where &'a Self: for<'a> IntoIterator,

Formats each item in a sequence. Read more
Source§

impl<T> From<T> for T

Source§

fn from(t: T) -> T

Returns the argument unchanged.

§

impl<TxEnv, T> FromRecoveredTx<&T> for TxEnv
where TxEnv: FromRecoveredTx<T>,

§

fn from_recovered_tx(tx: &&T, sender: Address) -> TxEnv

Builds a [TxEnv] from a transaction and a sender address.
§

impl<TxEnv, T> FromTxWithEncoded<&T> for TxEnv
where TxEnv: FromTxWithEncoded<T>,

§

fn from_encoded_tx(tx: &&T, sender: Address, encoded: Bytes) -> TxEnv

Builds a [TxEnv] from a transaction, its sender, and encoded transaction bytes.
§

impl<T> Instrument for T

§

fn instrument(self, span: Span) -> Instrumented<Self>

Instruments this type with the provided [Span], returning an Instrumented wrapper. Read more
§

fn in_current_span(self) -> Instrumented<Self>

Instruments this type with the current Span, returning an Instrumented wrapper. Read more
Source§

impl<T, U> Into<U> for T
where U: From<T>,

Source§

fn into(self) -> U

Calls U::from(self).

That is, this conversion is whatever the implementation of From<T> for U chooses to do.

Source§

impl<T> IntoEither for T

Source§

fn into_either(self, into_left: bool) -> Either<Self, Self>

Converts self into a Left variant of Either<Self, Self> if into_left is true. Converts self into a Right variant of Either<Self, Self> otherwise. Read more
Source§

fn into_either_with<F>(self, into_left: F) -> Either<Self, Self>
where F: FnOnce(&Self) -> bool,

Converts self into a Left variant of Either<Self, Self> if into_left(&self) returns true. Converts self into a Right variant of Either<Self, Self> otherwise. Read more
§

impl<T> Pipe for T
where T: ?Sized,

§

fn pipe<R>(self, func: impl FnOnce(Self) -> R) -> R
where Self: Sized,

Pipes by value. This is generally the method you want to use. Read more
§

fn pipe_ref<'a, R>(&'a self, func: impl FnOnce(&'a Self) -> R) -> R
where R: 'a,

Borrows self and passes that borrow into the pipe function. Read more
§

fn pipe_ref_mut<'a, R>(&'a mut self, func: impl FnOnce(&'a mut Self) -> R) -> R
where R: 'a,

Mutably borrows self and passes that borrow into the pipe function. Read more
§

fn pipe_borrow<'a, B, R>(&'a self, func: impl FnOnce(&'a B) -> R) -> R
where Self: Borrow<B>, B: 'a + ?Sized, R: 'a,

Borrows self, then passes self.borrow() into the pipe function. Read more
§

fn pipe_borrow_mut<'a, B, R>( &'a mut self, func: impl FnOnce(&'a mut B) -> R, ) -> R
where Self: BorrowMut<B>, B: 'a + ?Sized, R: 'a,

Mutably borrows self, then passes self.borrow_mut() into the pipe function. Read more
§

fn pipe_as_ref<'a, U, R>(&'a self, func: impl FnOnce(&'a U) -> R) -> R
where Self: AsRef<U>, U: 'a + ?Sized, R: 'a,

Borrows self, then passes self.as_ref() into the pipe function.
§

fn pipe_as_mut<'a, U, R>(&'a mut self, func: impl FnOnce(&'a mut U) -> R) -> R
where Self: AsMut<U>, U: 'a + ?Sized, R: 'a,

Mutably borrows self, then passes self.as_mut() into the pipe function.
§

fn pipe_deref<'a, T, R>(&'a self, func: impl FnOnce(&'a T) -> R) -> R
where Self: Deref<Target = T>, T: 'a + ?Sized, R: 'a,

Borrows self, then passes self.deref() into the pipe function.
§

fn pipe_deref_mut<'a, T, R>( &'a mut self, func: impl FnOnce(&'a mut T) -> R, ) -> R
where Self: DerefMut<Target = T> + Deref, T: 'a + ?Sized, R: 'a,

Mutably borrows self, then passes self.deref_mut() into the pipe function.
§

impl<T> Pointable for T

§

const ALIGN: usize

The alignment of pointer.
§

type Init = T

The type for initializers.
§

unsafe fn init(init: <T as Pointable>::Init) -> usize

Initializes a with the given initializer. Read more
§

unsafe fn deref<'a>(ptr: usize) -> &'a T

Dereferences the given pointer. Read more
§

unsafe fn deref_mut<'a>(ptr: usize) -> &'a mut T

Mutably dereferences the given pointer. Read more
§

unsafe fn drop(ptr: usize)

Drops the object pointed to by the given pointer. Read more
§

impl<T> PolicyExt for T
where T: ?Sized,

§

fn and<P, B, E>(self, other: P) -> And<T, P>
where T: Policy<B, E>, P: Policy<B, E>,

Create a new Policy that returns [Action::Follow] only if self and other return Action::Follow. Read more
§

fn or<P, B, E>(self, other: P) -> Or<T, P>
where T: Policy<B, E>, P: Policy<B, E>,

Create a new Policy that returns [Action::Follow] if either self or other returns Action::Follow. Read more
Source§

impl<T> Same for T

Source§

type Output = T

Should always be Self
§

impl<T> ServiceExt for T

§

fn propagate_header(self, header: HeaderName) -> PropagateHeader<Self>
where Self: Sized,

Propagate a header from the request to the response. Read more
§

fn add_extension<T>(self, value: T) -> AddExtension<Self, T>
where Self: Sized,

Add some shareable value to request extensions. Read more
§

fn map_request_body<F>(self, f: F) -> MapRequestBody<Self, F>
where Self: Sized,

Apply a transformation to the request body. Read more
§

fn map_response_body<F>(self, f: F) -> MapResponseBody<Self, F>
where Self: Sized,

Apply a transformation to the response body. Read more
§

fn compression(self) -> Compression<Self>
where Self: Sized,

Compresses response bodies. Read more
§

fn decompression(self) -> Decompression<Self>
where Self: Sized,

Decompress response bodies. Read more
§

fn trace_for_http(self) -> Trace<Self, SharedClassifier<ServerErrorsAsFailures>>
where Self: Sized,

High level tracing that classifies responses using HTTP status codes. Read more
§

fn trace_for_grpc(self) -> Trace<Self, SharedClassifier<GrpcErrorsAsFailures>>
where Self: Sized,

High level tracing that classifies responses using gRPC headers. Read more
§

fn follow_redirects(self) -> FollowRedirect<Self>
where Self: Sized,

Follow redirect resposes using the Standard policy. Read more
§

fn sensitive_headers( self, headers: impl IntoIterator<Item = HeaderName>, ) -> SetSensitiveRequestHeaders<SetSensitiveResponseHeaders<Self>>
where Self: Sized,

Mark headers as sensitive on both requests and responses. Read more
§

fn sensitive_request_headers( self, headers: impl IntoIterator<Item = HeaderName>, ) -> SetSensitiveRequestHeaders<Self>
where Self: Sized,

Mark headers as sensitive on requests. Read more
§

fn sensitive_response_headers( self, headers: impl IntoIterator<Item = HeaderName>, ) -> SetSensitiveResponseHeaders<Self>
where Self: Sized,

Mark headers as sensitive on responses. Read more
§

fn override_request_header<M>( self, header_name: HeaderName, make: M, ) -> SetRequestHeader<Self, M>
where Self: Sized,

Insert a header into the request. Read more
§

fn append_request_header<M>( self, header_name: HeaderName, make: M, ) -> SetRequestHeader<Self, M>
where Self: Sized,

Append a header into the request. Read more
§

fn insert_request_header_if_not_present<M>( self, header_name: HeaderName, make: M, ) -> SetRequestHeader<Self, M>
where Self: Sized,

Insert a header into the request, if the header is not already present. Read more
§

fn override_response_header<M>( self, header_name: HeaderName, make: M, ) -> SetResponseHeader<Self, M>
where Self: Sized,

Insert a header into the response. Read more
§

fn append_response_header<M>( self, header_name: HeaderName, make: M, ) -> SetResponseHeader<Self, M>
where Self: Sized,

Append a header into the response. Read more
§

fn insert_response_header_if_not_present<M>( self, header_name: HeaderName, make: M, ) -> SetResponseHeader<Self, M>
where Self: Sized,

Insert a header into the response, if the header is not already present. Read more
§

fn set_request_id<M>( self, header_name: HeaderName, make_request_id: M, ) -> SetRequestId<Self, M>
where Self: Sized, M: MakeRequestId,

Add request id header and extension. Read more
§

fn set_x_request_id<M>(self, make_request_id: M) -> SetRequestId<Self, M>
where Self: Sized, M: MakeRequestId,

Add request id header and extension, using x-request-id as the header name. Read more
§

fn propagate_request_id( self, header_name: HeaderName, ) -> PropagateRequestId<Self>
where Self: Sized,

Propgate request ids from requests to responses. Read more
§

fn propagate_x_request_id(self) -> PropagateRequestId<Self>
where Self: Sized,

Propgate request ids from requests to responses, using x-request-id as the header name. Read more
§

fn catch_panic(self) -> CatchPanic<Self, DefaultResponseForPanic>
where Self: Sized,

Catch panics and convert them into 500 Internal Server responses. Read more
§

fn request_body_limit(self, limit: usize) -> RequestBodyLimit<Self>
where Self: Sized,

Intercept requests with over-sized payloads and convert them into 413 Payload Too Large responses. Read more
§

fn trim_trailing_slash(self) -> NormalizePath<Self>
where Self: Sized,

Remove trailing slashes from paths. Read more
§

fn append_trailing_slash(self) -> NormalizePath<Self>
where Self: Sized,

Append trailing slash to paths. Read more
§

impl<T> Tap for T

§

fn tap(self, func: impl FnOnce(&Self)) -> Self

Immutable access to a value. Read more
§

fn tap_mut(self, func: impl FnOnce(&mut Self)) -> Self

Mutable access to a value. Read more
§

fn tap_borrow<B>(self, func: impl FnOnce(&B)) -> Self
where Self: Borrow<B>, B: ?Sized,

Immutable access to the Borrow<B> of a value. Read more
§

fn tap_borrow_mut<B>(self, func: impl FnOnce(&mut B)) -> Self
where Self: BorrowMut<B>, B: ?Sized,

Mutable access to the BorrowMut<B> of a value. Read more
§

fn tap_ref<R>(self, func: impl FnOnce(&R)) -> Self
where Self: AsRef<R>, R: ?Sized,

Immutable access to the AsRef<R> view of a value. Read more
§

fn tap_ref_mut<R>(self, func: impl FnOnce(&mut R)) -> Self
where Self: AsMut<R>, R: ?Sized,

Mutable access to the AsMut<R> view of a value. Read more
§

fn tap_deref<T>(self, func: impl FnOnce(&T)) -> Self
where Self: Deref<Target = T>, T: ?Sized,

Immutable access to the Deref::Target of a value. Read more
§

fn tap_deref_mut<T>(self, func: impl FnOnce(&mut T)) -> Self
where Self: DerefMut<Target = T> + Deref, T: ?Sized,

Mutable access to the Deref::Target of a value. Read more
§

fn tap_dbg(self, func: impl FnOnce(&Self)) -> Self

Calls .tap() only in debug builds, and is erased in release builds.
§

fn tap_mut_dbg(self, func: impl FnOnce(&mut Self)) -> Self

Calls .tap_mut() only in debug builds, and is erased in release builds.
§

fn tap_borrow_dbg<B>(self, func: impl FnOnce(&B)) -> Self
where Self: Borrow<B>, B: ?Sized,

Calls .tap_borrow() only in debug builds, and is erased in release builds.
§

fn tap_borrow_mut_dbg<B>(self, func: impl FnOnce(&mut B)) -> Self
where Self: BorrowMut<B>, B: ?Sized,

Calls .tap_borrow_mut() only in debug builds, and is erased in release builds.
§

fn tap_ref_dbg<R>(self, func: impl FnOnce(&R)) -> Self
where Self: AsRef<R>, R: ?Sized,

Calls .tap_ref() only in debug builds, and is erased in release builds.
§

fn tap_ref_mut_dbg<R>(self, func: impl FnOnce(&mut R)) -> Self
where Self: AsMut<R>, R: ?Sized,

Calls .tap_ref_mut() only in debug builds, and is erased in release builds.
§

fn tap_deref_dbg<T>(self, func: impl FnOnce(&T)) -> Self
where Self: Deref<Target = T>, T: ?Sized,

Calls .tap_deref() only in debug builds, and is erased in release builds.
§

fn tap_deref_mut_dbg<T>(self, func: impl FnOnce(&mut T)) -> Self
where Self: DerefMut<Target = T> + Deref, T: ?Sized,

Calls .tap_deref_mut() only in debug builds, and is erased in release builds.
§

impl<T> TryConv for T

§

fn try_conv<T>(self) -> Result<T, Self::Error>
where Self: TryInto<T>,

Attempts to convert self into T using TryInto<T>. Read more
Source§

impl<T, U> TryFrom<U> for T
where U: Into<T>,

Source§

type Error = Infallible

The type returned in the event of a conversion error.
Source§

fn try_from(value: U) -> Result<T, <T as TryFrom<U>>::Error>

Performs the conversion.
Source§

impl<T, U> TryInto<U> for T
where U: TryFrom<T>,

Source§

type Error = <U as TryFrom<T>>::Error

The type returned in the event of a conversion error.
Source§

fn try_into(self) -> Result<U, <U as TryFrom<T>>::Error>

Performs the conversion.
§

impl<V, T> VZip<V> for T
where V: MultiLane<T>,

§

fn vzip(self) -> V

§

impl<T> WithSubscriber for T

§

fn with_subscriber<S>(self, subscriber: S) -> WithDispatch<Self>
where S: Into<Dispatch>,

Attaches the provided Subscriber to this type, returning a [WithDispatch] wrapper. Read more
§

fn with_current_subscriber(self) -> WithDispatch<Self>

Attaches the current default Subscriber to this type, returning a [WithDispatch] wrapper. Read more
§

impl<T> AccountInfoReader for T
where T: AccountReader + BytecodeReader,

§

impl<T> ErasedDestructor for T
where T: 'static,

§

impl<T> MaybeDebug for T
where T: Debug,

Layout§

Note: Unable to compute type layout, possibly due to this type having generic parameters. Layout can only be computed for concrete, fully-instantiated types.