Struct MockEthProvider

pub struct MockEthProvider<T = TransactionSigned, ChainSpec = ChainSpec> {
    pub blocks: Arc<Mutex<RawMutex, HashMap<FixedBytes<32>, Block<T>, RandomState>>>,
    pub headers: Arc<Mutex<RawMutex, HashMap<FixedBytes<32>, Header, RandomState>>>,
    pub accounts: Arc<Mutex<RawMutex, HashMap<Address, ExtendedAccount, RandomState>>>,
    pub chain_spec: Arc<ChainSpec>,
    pub state_roots: Arc<Mutex<RawMutex, Vec<FixedBytes<32>>>>,
}
Available on crate feature test-utils only.
Expand description

A mock implementation for Provider interfaces.

Fields§

§blocks: Arc<Mutex<RawMutex, HashMap<FixedBytes<32>, Block<T>, RandomState>>>

Local block store

§headers: Arc<Mutex<RawMutex, HashMap<FixedBytes<32>, Header, RandomState>>>

Local header store

§accounts: Arc<Mutex<RawMutex, HashMap<Address, ExtendedAccount, RandomState>>>

Local account store

§chain_spec: Arc<ChainSpec>

Local chain spec

§state_roots: Arc<Mutex<RawMutex, Vec<FixedBytes<32>>>>

Local state roots

Implementations§

§

impl<T> MockEthProvider<T>

pub fn new() -> MockEthProvider<T>

Create a new, empty instance

§

impl<T, ChainSpec> MockEthProvider<T, ChainSpec>

pub fn add_block(&self, hash: FixedBytes<32>, block: Block<T>)

Add block to local block store

pub fn extend_blocks( &self, iter: impl IntoIterator<Item = (FixedBytes<32>, Block<T>)>, )

Add multiple blocks to local block store

pub fn add_header(&self, hash: FixedBytes<32>, header: Header)

Add header to local header store

pub fn extend_headers( &self, iter: impl IntoIterator<Item = (FixedBytes<32>, Header)>, )

Add multiple headers to local header store

pub fn add_account(&self, address: Address, account: ExtendedAccount)

Add account to local account store

pub fn extend_accounts( &self, iter: impl IntoIterator<Item = (Address, ExtendedAccount)>, )

Add account to local account store

pub fn add_state_root(&self, state_root: FixedBytes<32>)

Add state root to local state root store

pub fn with_chain_spec<C>(self, chain_spec: C) -> MockEthProvider<T, C>

Set chain spec.

Trait Implementations§

§

impl<T, ChainSpec> AccountReader for MockEthProvider<T, ChainSpec>
where T: Transaction, ChainSpec: EthChainSpec,

§

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

Get basic account information. Read more
§

impl<T, ChainSpec> BlockBodyIndicesProvider for MockEthProvider<T, ChainSpec>
where T: Transaction, ChainSpec: EthChainSpec,

§

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

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

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.
§

impl<T, ChainSpec> BlockHashReader for MockEthProvider<T, ChainSpec>
where T: Transaction, ChainSpec: EthChainSpec,

§

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

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

fn canonical_hashes_range( &self, start: u64, end: u64, ) -> Result<Vec<FixedBytes<32>>, 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.
§

impl<T, ChainSpec> BlockIdReader for MockEthProvider<T, ChainSpec>
where T: Transaction, ChainSpec: EthChainSpec,

§

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

Get the current pending block number and hash.
§

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

Get the current safe block number and hash.
§

fn finalized_block_num_hash(&self) -> Result<Option<NumHash>, 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 block_number_for_id( &self, block_id: BlockId, ) -> Result<Option<u64>, ProviderError>

Get the number 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.
§

impl<T, ChainSpec> BlockNumReader for MockEthProvider<T, ChainSpec>
where T: Transaction, ChainSpec: EthChainSpec,

§

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

Returns the current info for the chain.
§

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

Returns the best block number in the chain.
§

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

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

fn block_number( &self, hash: FixedBytes<32>, ) -> Result<Option<u64>, ProviderError>

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

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.
§

impl<T, ChainSpec> BlockReader for MockEthProvider<T, ChainSpec>
where T: SignedTransaction, ChainSpec: EthChainSpec,

§

type Block = Block<T>

The block type this provider reads.
§

fn find_block_by_hash( &self, hash: FixedBytes<32>, _source: BlockSource, ) -> Result<Option<<MockEthProvider<T, ChainSpec> as BlockReader>::Block>, ProviderError>

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

fn block( &self, id: HashOrNumber, ) -> Result<Option<<MockEthProvider<T, ChainSpec> as BlockReader>::Block>, ProviderError>

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

fn pending_block( &self, ) -> Result<Option<SealedBlock<<MockEthProvider<T, ChainSpec> as BlockReader>::Block>>, ProviderError>

Returns the pending block if available Read more
§

fn pending_block_with_senders( &self, ) -> Result<Option<RecoveredBlock<<MockEthProvider<T, ChainSpec> as BlockReader>::Block>>, ProviderError>

Returns the pending block if available Read more
§

fn pending_block_and_receipts( &self, ) -> Result<Option<(SealedBlock<<MockEthProvider<T, ChainSpec> as BlockReader>::Block>, Vec<Receipt>)>, ProviderError>

Returns the pending block and receipts if available.
§

fn block_with_senders( &self, _id: HashOrNumber, _transaction_kind: TransactionVariant, ) -> Result<Option<RecoveredBlock<<MockEthProvider<T, ChainSpec> as BlockReader>::Block>>, ProviderError>

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

fn sealed_block_with_senders( &self, _id: HashOrNumber, _transaction_kind: TransactionVariant, ) -> Result<Option<RecoveredBlock<<MockEthProvider<T, ChainSpec> as BlockReader>::Block>>, ProviderError>

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

fn block_range( &self, range: RangeInclusive<u64>, ) -> Result<Vec<<MockEthProvider<T, ChainSpec> as BlockReader>::Block>, ProviderError>

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

fn block_with_senders_range( &self, _range: RangeInclusive<u64>, ) -> Result<Vec<RecoveredBlock<<MockEthProvider<T, ChainSpec> as BlockReader>::Block>>, ProviderError>

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

fn sealed_block_with_senders_range( &self, _range: RangeInclusive<u64>, ) -> Result<Vec<RecoveredBlock<<MockEthProvider<T, ChainSpec> as BlockReader>::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
§

impl<T, ChainSpec> BlockReaderIdExt for MockEthProvider<T, ChainSpec>
where T: SignedTransaction, ChainSpec: EthChainSpec,

§

fn block_by_id(&self, id: BlockId) -> Result<Option<Block<T>>, ProviderError>

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

fn sealed_header_by_id( &self, id: BlockId, ) -> Result<Option<SealedHeader>, ProviderError>

Returns the sealed header with the matching BlockId from the database. Read more
§

fn header_by_id(&self, id: BlockId) -> Result<Option<Header>, ProviderError>

Returns the header with the matching BlockId from the database. Read more
§

fn ommers_by_id( &self, id: BlockId, ) -> Result<Option<Vec<Header>>, ProviderError>

Returns the ommers with the matching BlockId from the database. Read more
§

fn block_by_number_or_tag( &self, id: BlockNumberOrTag, ) -> Result<Option<Self::Block>, ProviderError>

Returns the block with matching tag from the database Read more
§

fn pending_header( &self, ) -> Result<Option<SealedHeader<Self::Header>>, ProviderError>

Returns the pending block header if available Read more
§

fn latest_header( &self, ) -> Result<Option<SealedHeader<Self::Header>>, ProviderError>

Returns the latest block header if available Read more
§

fn safe_header( &self, ) -> Result<Option<SealedHeader<Self::Header>>, ProviderError>

Returns the safe block header if available Read more
§

fn finalized_header( &self, ) -> Result<Option<SealedHeader<Self::Header>>, ProviderError>

Returns the finalized block header if available Read more
§

fn block_with_senders_by_id( &self, id: BlockId, transaction_kind: TransactionVariant, ) -> Result<Option<RecoveredBlock<Self::Block>>, ProviderError>

Returns the block with senders with matching BlockId. Read more
§

fn header_by_number_or_tag( &self, id: BlockNumberOrTag, ) -> Result<Option<Self::Header>, ProviderError>

Returns the header with matching tag from the database Read more
§

fn sealed_header_by_number_or_tag( &self, id: BlockNumberOrTag, ) -> Result<Option<SealedHeader<Self::Header>>, ProviderError>

Returns the header with matching tag from the database Read more
§

fn ommers_by_number_or_tag( &self, id: BlockNumberOrTag, ) -> Result<Option<Vec<Self::Header>>, ProviderError>

Returns the ommers with the matching tag from the database.
§

impl<T, ChainSpec> ChainSpecProvider for MockEthProvider<T, ChainSpec>
where T: Transaction, ChainSpec: EthChainSpec + 'static,

§

type ChainSpec = ChainSpec

The chain spec type.
§

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

Get an Arc to the chainspec.
§

impl<T, ChainSpec> ChangeSetReader for MockEthProvider<T, ChainSpec>
where T: Transaction, ChainSpec: EthChainSpec,

§

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

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

impl<T, ChainSpec> Clone for MockEthProvider<T, ChainSpec>

§

fn clone(&self) -> MockEthProvider<T, ChainSpec>

Returns a copy of the value. Read more
1.0.0 · Source§

fn clone_from(&mut self, source: &Self)

Performs copy-assignment from source. Read more
§

impl<T, ChainSpec> DatabaseProviderFactory for MockEthProvider<T, ChainSpec>
where T: Transaction, ChainSpec: EthChainSpec,

§

type DB = DatabaseMock

Database this factory produces providers for.
§

type Provider = DatabaseProvider<TxMock, MockNode>

Provider type returned by the factory.
§

type ProviderRW = DatabaseProvider<TxMock, MockNode>

Read-write provider type returned by the factory.
§

fn database_provider_ro( &self, ) -> Result<<MockEthProvider<T, ChainSpec> as DatabaseProviderFactory>::Provider, ProviderError>

Create new read-only database provider.
§

fn database_provider_rw( &self, ) -> Result<<MockEthProvider<T, ChainSpec> as DatabaseProviderFactory>::ProviderRW, ProviderError>

Create new read-write database provider.
§

impl<T, ChainSpec> Debug for MockEthProvider<T, ChainSpec>
where T: Debug, ChainSpec: Debug,

§

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

Formats the value using the given formatter. Read more
§

impl Default for MockEthProvider

§

fn default() -> MockEthProvider

Returns the “default value” for a type. Read more
§

impl<T, ChainSpec> HashedPostStateProvider for MockEthProvider<T, ChainSpec>
where T: Transaction, ChainSpec: EthChainSpec + 'static,

§

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

Returns the HashedPostState of the provided BundleState.
§

impl<T, ChainSpec> HeaderProvider for MockEthProvider<T, ChainSpec>
where T: Transaction, ChainSpec: EthChainSpec,

§

type Header = Header

The header type this provider supports.
§

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

Get header by block hash
§

fn header_by_number(&self, num: u64) -> Result<Option<Header>, ProviderError>

Get header by block number
§

fn header_td( &self, hash: &FixedBytes<32>, ) -> Result<Option<Uint<256, 4>>, ProviderError>

Get total difficulty by block hash.
§

fn header_td_by_number( &self, number: u64, ) -> Result<Option<Uint<256, 4>>, ProviderError>

Get total difficulty by block number.
§

fn headers_range( &self, range: impl RangeBounds<u64>, ) -> Result<Vec<Header>, ProviderError>

Get headers in range of block numbers
§

fn sealed_header( &self, number: u64, ) -> Result<Option<SealedHeader>, ProviderError>

Get a single sealed header by block number.
§

fn sealed_headers_while( &self, range: impl RangeBounds<u64>, predicate: impl FnMut(&SealedHeader) -> bool, ) -> Result<Vec<SealedHeader>, 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
§

fn sealed_headers_range( &self, range: impl RangeBounds<u64>, ) -> Result<Vec<SealedHeader<Self::Header>>, ProviderError>

Get headers in range of block numbers.
§

impl<T, ChainSpec> OmmersProvider for MockEthProvider<T, ChainSpec>
where T: Transaction, ChainSpec: EthChainSpec,

§

fn ommers( &self, _id: HashOrNumber, ) -> Result<Option<Vec<Header>>, ProviderError>

Returns the ommers/uncle headers of the given block from the database. Read more
§

impl<T, ChainSpec> ReceiptProvider for MockEthProvider<T, ChainSpec>
where T: Transaction, ChainSpec: EthChainSpec,

§

type Receipt = Receipt

The receipt type.
§

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

Get receipt by transaction number Read more
§

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

Get receipt by transaction hash. Read more
§

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

Get receipts by block num or hash. Read more
§

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

Get receipts by tx range.
§

impl<T, ChainSpec> ReceiptProviderIdExt for MockEthProvider<T, ChainSpec>
where T: Transaction, ChainSpec: EthChainSpec,

§

fn receipts_by_block_id( &self, block: BlockId, ) -> Result<Option<Vec<Self::Receipt>>, ProviderError>

Get receipt by block id
§

fn receipts_by_number_or_tag( &self, number_or_tag: BlockNumberOrTag, ) -> Result<Option<Vec<Self::Receipt>>, ProviderError>

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

impl<T, ChainSpec> StageCheckpointReader for MockEthProvider<T, ChainSpec>
where T: Transaction, ChainSpec: EthChainSpec,

§

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

Fetch the checkpoint for the given stage.
§

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

Get stage checkpoint progress.
§

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.
§

impl<T, ChainSpec> StateCommitmentProvider for MockEthProvider<T, ChainSpec>
where T: Transaction, ChainSpec: EthChainSpec,

§

type StateCommitment = <MockNode as NodeTypes>::StateCommitment

The [StateCommitment] type that can be used to perform state commitment operations.
§

impl<T, ChainSpec> StateProofProvider for MockEthProvider<T, ChainSpec>
where T: Transaction, ChainSpec: EthChainSpec,

§

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

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

fn multiproof( &self, _input: TrieInput, _targets: HashMap<FixedBytes<32>, HashSet<FixedBytes<32>, FbBuildHasher<32>>, FbBuildHasher<32>>, ) -> Result<MultiProof, ProviderError>

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

fn witness( &self, _input: TrieInput, _target: HashedPostState, ) -> Result<HashMap<FixedBytes<32>, Bytes, FbBuildHasher<32>>, ProviderError>

Get trie witness for provided state.
§

impl<T, ChainSpec> StateProvider for MockEthProvider<T, ChainSpec>
where T: Transaction, ChainSpec: EthChainSpec + 'static,

§

fn storage( &self, account: Address, storage_key: FixedBytes<32>, ) -> Result<Option<Uint<256, 4>>, ProviderError>

Get storage of given account.
§

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

Get account code by its hash
§

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

Get account code by its address. Read more
§

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

Get account balance by its address. Read more
§

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

Get account nonce by its address. Read more
§

impl<T, ChainSpec> StateProviderFactory for MockEthProvider<T, ChainSpec>
where T: SignedTransaction, ChainSpec: EthChainSpec + 'static,

§

fn latest(&self) -> Result<Box<dyn StateProvider>, ProviderError>

Storage provider for latest block.
§

fn state_by_block_number_or_tag( &self, number_or_tag: BlockNumberOrTag, ) -> Result<Box<dyn StateProvider>, ProviderError>

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

fn history_by_block_number( &self, _block: u64, ) -> Result<Box<dyn StateProvider>, ProviderError>

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

fn history_by_block_hash( &self, _block: FixedBytes<32>, ) -> Result<Box<dyn StateProvider>, ProviderError>

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

fn state_by_block_hash( &self, _block: FixedBytes<32>, ) -> Result<Box<dyn StateProvider>, ProviderError>

Returns any StateProvider with matching block hash. Read more
§

fn pending(&self) -> Result<Box<dyn StateProvider>, ProviderError>

Storage provider for pending state. Read more
§

fn pending_state_by_hash( &self, _block_hash: FixedBytes<32>, ) -> Result<Option<Box<dyn StateProvider>>, ProviderError>

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

fn state_by_block_id( &self, block_id: BlockId, ) -> Result<Box<dyn StateProvider>, ProviderError>

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

impl<T, ChainSpec> StateReader for MockEthProvider<T, ChainSpec>
where T: Transaction, ChainSpec: EthChainSpec,

§

type Receipt = Receipt

Receipt type in ExecutionOutcome.
§

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

Get the ExecutionOutcome for the given block
§

impl<T, ChainSpec> StateRootProvider for MockEthProvider<T, ChainSpec>
where T: Transaction, ChainSpec: EthChainSpec,

§

fn state_root( &self, _state: HashedPostState, ) -> Result<FixedBytes<32>, ProviderError>

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

fn state_root_from_nodes( &self, _input: TrieInput, ) -> Result<FixedBytes<32>, 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.
§

fn state_root_with_updates( &self, _state: HashedPostState, ) -> Result<(FixedBytes<32>, TrieUpdates), ProviderError>

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

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

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

impl<T, ChainSpec> StorageRootProvider for MockEthProvider<T, ChainSpec>
where T: Transaction, ChainSpec: EthChainSpec,

§

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

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

fn storage_proof( &self, _address: Address, slot: FixedBytes<32>, _hashed_storage: HashedStorage, ) -> Result<StorageProof, ProviderError>

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

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

Returns the storage multiproof for target slots.
§

impl<T, ChainSpec> TransactionsProvider for MockEthProvider<T, ChainSpec>
where T: SignedTransaction, ChainSpec: EthChainSpec,

§

type Transaction = T

The transaction type this provider reads.
§

fn transaction_id( &self, tx_hash: FixedBytes<32>, ) -> Result<Option<u64>, ProviderError>

Get internal transaction identifier by transaction hash. Read more
§

fn transaction_by_id( &self, id: u64, ) -> Result<Option<<MockEthProvider<T, ChainSpec> as TransactionsProvider>::Transaction>, ProviderError>

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

fn transaction_by_id_unhashed( &self, id: u64, ) -> Result<Option<<MockEthProvider<T, ChainSpec> as TransactionsProvider>::Transaction>, ProviderError>

Get transaction by id without computing the hash.
§

fn transaction_by_hash( &self, hash: FixedBytes<32>, ) -> Result<Option<<MockEthProvider<T, ChainSpec> as TransactionsProvider>::Transaction>, ProviderError>

Get transaction by transaction hash.
§

fn transaction_by_hash_with_meta( &self, hash: FixedBytes<32>, ) -> Result<Option<(<MockEthProvider<T, ChainSpec> as TransactionsProvider>::Transaction, TransactionMeta)>, ProviderError>

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

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

Get transaction block number
§

fn transactions_by_block( &self, id: HashOrNumber, ) -> Result<Option<Vec<<MockEthProvider<T, ChainSpec> as TransactionsProvider>::Transaction>>, ProviderError>

Get transactions by block id.
§

fn transactions_by_block_range( &self, range: impl RangeBounds<u64>, ) -> Result<Vec<Vec<<MockEthProvider<T, ChainSpec> as TransactionsProvider>::Transaction>>, ProviderError>

Get transactions by block range.
§

fn transactions_by_tx_range( &self, range: impl RangeBounds<u64>, ) -> Result<Vec<<MockEthProvider<T, ChainSpec> as TransactionsProvider>::Transaction>, ProviderError>

Get transactions by tx range.
§

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

Get Senders from a tx range.
§

fn transaction_sender(&self, id: u64) -> Result<Option<Address>, ProviderError>

Get transaction sender. Read more
§

impl<T, ChainSpec> WithdrawalsProvider for MockEthProvider<T, ChainSpec>
where T: Transaction, ChainSpec: EthChainSpec,

§

fn withdrawals_by_block( &self, _id: HashOrNumber, _timestamp: u64, ) -> Result<Option<Withdrawals>, ProviderError>

Get withdrawals by block id.

Auto Trait Implementations§

§

impl<T, ChainSpec> Freeze for MockEthProvider<T, ChainSpec>

§

impl<T = TransactionSigned, ChainSpec = ChainSpec> !RefUnwindSafe for MockEthProvider<T, ChainSpec>

§

impl<T, ChainSpec> Send for MockEthProvider<T, ChainSpec>
where ChainSpec: Sync + Send, T: Send,

§

impl<T, ChainSpec> Sync for MockEthProvider<T, ChainSpec>
where ChainSpec: Sync + Send, T: Send,

§

impl<T, ChainSpec> Unpin for MockEthProvider<T, ChainSpec>

§

impl<T = TransactionSigned, ChainSpec = ChainSpec> !UnwindSafe for MockEthProvider<T, ChainSpec>

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
Source§

impl<T> CloneToUninit for T
where T: Clone,

Source§

unsafe fn clone_to_uninit(&self, dst: *mut u8)

🔬This is a nightly-only experimental API. (clone_to_uninit #126799)
Performs copy-assignment from self to dst. 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
Source§

impl<T> DynClone for T
where T: Clone,

Source§

fn __clone_box(&self, _: Private) -> *mut ()

§

impl<T> EvmStateProvider for T
where T: StateProvider,

§

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

Get basic account information. Read more
§

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

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

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

Get account code by hash.
§

fn storage( &self, account: Address, storage_key: FixedBytes<32>, ) -> Result<Option<Uint<256, 4>>, ProviderError>

Get storage of the given account.
§

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<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> Instrument for T

Source§

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

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

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> Paint for T
where T: ?Sized,

§

fn fg(&self, value: Color) -> Painted<&T>

Returns a styled value derived from self with the foreground set to value.

This method should be used rarely. Instead, prefer to use color-specific builder methods like red() and green(), which have the same functionality but are pithier.

§Example

Set foreground color to white using fg():

use yansi::{Paint, Color};

painted.fg(Color::White);

Set foreground color to white using white().

use yansi::Paint;

painted.white();
§

fn primary(&self) -> Painted<&T>

Returns self with the fg() set to [Color::Primary].

§Example
println!("{}", value.primary());
§

fn fixed(&self, color: u8) -> Painted<&T>

Returns self with the fg() set to [Color::Fixed].

§Example
println!("{}", value.fixed(color));
§

fn rgb(&self, r: u8, g: u8, b: u8) -> Painted<&T>

Returns self with the fg() set to [Color::Rgb].

§Example
println!("{}", value.rgb(r, g, b));
§

fn black(&self) -> Painted<&T>

Returns self with the fg() set to [Color::Black].

§Example
println!("{}", value.black());
§

fn red(&self) -> Painted<&T>

Returns self with the fg() set to [Color::Red].

§Example
println!("{}", value.red());
§

fn green(&self) -> Painted<&T>

Returns self with the fg() set to [Color::Green].

§Example
println!("{}", value.green());
§

fn yellow(&self) -> Painted<&T>

Returns self with the fg() set to [Color::Yellow].

§Example
println!("{}", value.yellow());
§

fn blue(&self) -> Painted<&T>

Returns self with the fg() set to [Color::Blue].

§Example
println!("{}", value.blue());
§

fn magenta(&self) -> Painted<&T>

Returns self with the fg() set to [Color::Magenta].

§Example
println!("{}", value.magenta());
§

fn cyan(&self) -> Painted<&T>

Returns self with the fg() set to [Color::Cyan].

§Example
println!("{}", value.cyan());
§

fn white(&self) -> Painted<&T>

Returns self with the fg() set to [Color::White].

§Example
println!("{}", value.white());
§

fn bright_black(&self) -> Painted<&T>

Returns self with the fg() set to [Color::BrightBlack].

§Example
println!("{}", value.bright_black());
§

fn bright_red(&self) -> Painted<&T>

Returns self with the fg() set to [Color::BrightRed].

§Example
println!("{}", value.bright_red());
§

fn bright_green(&self) -> Painted<&T>

Returns self with the fg() set to [Color::BrightGreen].

§Example
println!("{}", value.bright_green());
§

fn bright_yellow(&self) -> Painted<&T>

Returns self with the fg() set to [Color::BrightYellow].

§Example
println!("{}", value.bright_yellow());
§

fn bright_blue(&self) -> Painted<&T>

Returns self with the fg() set to [Color::BrightBlue].

§Example
println!("{}", value.bright_blue());
§

fn bright_magenta(&self) -> Painted<&T>

Returns self with the fg() set to [Color::BrightMagenta].

§Example
println!("{}", value.bright_magenta());
§

fn bright_cyan(&self) -> Painted<&T>

Returns self with the fg() set to [Color::BrightCyan].

§Example
println!("{}", value.bright_cyan());
§

fn bright_white(&self) -> Painted<&T>

Returns self with the fg() set to [Color::BrightWhite].

§Example
println!("{}", value.bright_white());
§

fn bg(&self, value: Color) -> Painted<&T>

Returns a styled value derived from self with the background set to value.

This method should be used rarely. Instead, prefer to use color-specific builder methods like on_red() and on_green(), which have the same functionality but are pithier.

§Example

Set background color to red using fg():

use yansi::{Paint, Color};

painted.bg(Color::Red);

Set background color to red using on_red().

use yansi::Paint;

painted.on_red();
§

fn on_primary(&self) -> Painted<&T>

Returns self with the bg() set to [Color::Primary].

§Example
println!("{}", value.on_primary());
§

fn on_fixed(&self, color: u8) -> Painted<&T>

Returns self with the bg() set to [Color::Fixed].

§Example
println!("{}", value.on_fixed(color));
§

fn on_rgb(&self, r: u8, g: u8, b: u8) -> Painted<&T>

Returns self with the bg() set to [Color::Rgb].

§Example
println!("{}", value.on_rgb(r, g, b));
§

fn on_black(&self) -> Painted<&T>

Returns self with the bg() set to [Color::Black].

§Example
println!("{}", value.on_black());
§

fn on_red(&self) -> Painted<&T>

Returns self with the bg() set to [Color::Red].

§Example
println!("{}", value.on_red());
§

fn on_green(&self) -> Painted<&T>

Returns self with the bg() set to [Color::Green].

§Example
println!("{}", value.on_green());
§

fn on_yellow(&self) -> Painted<&T>

Returns self with the bg() set to [Color::Yellow].

§Example
println!("{}", value.on_yellow());
§

fn on_blue(&self) -> Painted<&T>

Returns self with the bg() set to [Color::Blue].

§Example
println!("{}", value.on_blue());
§

fn on_magenta(&self) -> Painted<&T>

Returns self with the bg() set to [Color::Magenta].

§Example
println!("{}", value.on_magenta());
§

fn on_cyan(&self) -> Painted<&T>

Returns self with the bg() set to [Color::Cyan].

§Example
println!("{}", value.on_cyan());
§

fn on_white(&self) -> Painted<&T>

Returns self with the bg() set to [Color::White].

§Example
println!("{}", value.on_white());
§

fn on_bright_black(&self) -> Painted<&T>

Returns self with the bg() set to [Color::BrightBlack].

§Example
println!("{}", value.on_bright_black());
§

fn on_bright_red(&self) -> Painted<&T>

Returns self with the bg() set to [Color::BrightRed].

§Example
println!("{}", value.on_bright_red());
§

fn on_bright_green(&self) -> Painted<&T>

Returns self with the bg() set to [Color::BrightGreen].

§Example
println!("{}", value.on_bright_green());
§

fn on_bright_yellow(&self) -> Painted<&T>

Returns self with the bg() set to [Color::BrightYellow].

§Example
println!("{}", value.on_bright_yellow());
§

fn on_bright_blue(&self) -> Painted<&T>

Returns self with the bg() set to [Color::BrightBlue].

§Example
println!("{}", value.on_bright_blue());
§

fn on_bright_magenta(&self) -> Painted<&T>

Returns self with the bg() set to [Color::BrightMagenta].

§Example
println!("{}", value.on_bright_magenta());
§

fn on_bright_cyan(&self) -> Painted<&T>

Returns self with the bg() set to [Color::BrightCyan].

§Example
println!("{}", value.on_bright_cyan());
§

fn on_bright_white(&self) -> Painted<&T>

Returns self with the bg() set to [Color::BrightWhite].

§Example
println!("{}", value.on_bright_white());
§

fn attr(&self, value: Attribute) -> Painted<&T>

Enables the styling [Attribute] value.

This method should be used rarely. Instead, prefer to use attribute-specific builder methods like bold() and underline(), which have the same functionality but are pithier.

§Example

Make text bold using attr():

use yansi::{Paint, Attribute};

painted.attr(Attribute::Bold);

Make text bold using using bold().

use yansi::Paint;

painted.bold();
§

fn bold(&self) -> Painted<&T>

Returns self with the attr() set to [Attribute::Bold].

§Example
println!("{}", value.bold());
§

fn dim(&self) -> Painted<&T>

Returns self with the attr() set to [Attribute::Dim].

§Example
println!("{}", value.dim());
§

fn italic(&self) -> Painted<&T>

Returns self with the attr() set to [Attribute::Italic].

§Example
println!("{}", value.italic());
§

fn underline(&self) -> Painted<&T>

Returns self with the attr() set to [Attribute::Underline].

§Example
println!("{}", value.underline());

Returns self with the attr() set to [Attribute::Blink].

§Example
println!("{}", value.blink());

Returns self with the attr() set to [Attribute::RapidBlink].

§Example
println!("{}", value.rapid_blink());
§

fn invert(&self) -> Painted<&T>

Returns self with the attr() set to [Attribute::Invert].

§Example
println!("{}", value.invert());
§

fn conceal(&self) -> Painted<&T>

Returns self with the attr() set to [Attribute::Conceal].

§Example
println!("{}", value.conceal());
§

fn strike(&self) -> Painted<&T>

Returns self with the attr() set to [Attribute::Strike].

§Example
println!("{}", value.strike());
§

fn quirk(&self, value: Quirk) -> Painted<&T>

Enables the yansi [Quirk] value.

This method should be used rarely. Instead, prefer to use quirk-specific builder methods like mask() and wrap(), which have the same functionality but are pithier.

§Example

Enable wrapping using .quirk():

use yansi::{Paint, Quirk};

painted.quirk(Quirk::Wrap);

Enable wrapping using wrap().

use yansi::Paint;

painted.wrap();
§

fn mask(&self) -> Painted<&T>

Returns self with the quirk() set to [Quirk::Mask].

§Example
println!("{}", value.mask());
§

fn wrap(&self) -> Painted<&T>

Returns self with the quirk() set to [Quirk::Wrap].

§Example
println!("{}", value.wrap());
§

fn linger(&self) -> Painted<&T>

Returns self with the quirk() set to [Quirk::Linger].

§Example
println!("{}", value.linger());
§

fn clear(&self) -> Painted<&T>

👎Deprecated since 1.0.1: renamed to resetting() due to conflicts with Vec::clear(). The clear() method will be removed in a future release.

Returns self with the quirk() set to [Quirk::Clear].

§Example
println!("{}", value.clear());
§

fn resetting(&self) -> Painted<&T>

Returns self with the quirk() set to [Quirk::Resetting].

§Example
println!("{}", value.resetting());
§

fn bright(&self) -> Painted<&T>

Returns self with the quirk() set to [Quirk::Bright].

§Example
println!("{}", value.bright());
§

fn on_bright(&self) -> Painted<&T>

Returns self with the quirk() set to [Quirk::OnBright].

§Example
println!("{}", value.on_bright());
§

fn whenever(&self, value: Condition) -> Painted<&T>

Conditionally enable styling based on whether the [Condition] value applies. Replaces any previous condition.

See the crate level docs for more details.

§Example

Enable styling painted only when both stdout and stderr are TTYs:

use yansi::{Paint, Condition};

painted.red().on_yellow().whenever(Condition::STDOUTERR_ARE_TTY);
§

fn new(self) -> Painted<Self>
where Self: Sized,

Create a new [Painted] with a default [Style]. Read more
§

fn paint<S>(&self, style: S) -> Painted<&Self>
where S: Into<Style>,

Apply a style wholesale to self. Any previous style is replaced. 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> 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.
Source§

impl<T> ToOwned for T
where T: Clone,

Source§

type Owned = T

The resulting type after obtaining ownership.
Source§

fn to_owned(&self) -> T

Creates owned data from borrowed data, usually by cloning. Read more
Source§

fn clone_into(&self, target: &mut T)

Uses borrowed data to replace owned data, usually by cloning. Read more
§

impl<T> TryClone for T
where T: Clone,

§

fn try_clone(&self) -> Result<T, Error>

Clones self, possibly returning an error.
§

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
Source§

impl<T> WithSubscriber for T

Source§

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
Source§

fn with_current_subscriber(self) -> WithDispatch<Self>

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

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

§

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

§

impl<T> MaybeSend for T
where T: Send,

§

impl<T> MaybeSendSync for T

Layout§

Note: Most layout information is completely unstable and may even differ between compilations. The only exception is types with certain repr(...) attributes. Please see the Rust Reference's “Type Layout” chapter for details on type layout guarantees.

Size: 40 bytes