mirror of
https://github.com/hl-archive-node/nanoreth.git
synced 2025-12-06 10:59:55 +00:00
chore: Now cargo fmt sorts imports and trait methods
This commit is contained in:
@ -1,21 +1,21 @@
|
||||
use crate::{
|
||||
chainspec::{parser::HlChainSpecParser, HlChainSpec},
|
||||
node::{consensus::HlConsensus, evm::config::HlEvmConfig, storage::tables::Tables, HlNode},
|
||||
chainspec::{HlChainSpec, parser::HlChainSpecParser},
|
||||
node::{HlNode, consensus::HlConsensus, evm::config::HlEvmConfig, storage::tables::Tables},
|
||||
pseudo_peer::BlockSourceArgs,
|
||||
};
|
||||
use clap::{Args, Parser};
|
||||
use reth::{
|
||||
CliRunner,
|
||||
args::LogArgs,
|
||||
builder::{NodeBuilder, WithLaunchContext},
|
||||
cli::Commands,
|
||||
prometheus_exporter::install_prometheus_recorder,
|
||||
version::version_metadata,
|
||||
CliRunner,
|
||||
};
|
||||
use reth_chainspec::EthChainSpec;
|
||||
use reth_cli::chainspec::ChainSpecParser;
|
||||
use reth_cli_commands::{common::EnvironmentArgs, launcher::FnLauncher};
|
||||
use reth_db::{init_db, mdbx::init_db_for, DatabaseEnv};
|
||||
use reth_db::{DatabaseEnv, init_db, mdbx::init_db_for};
|
||||
use reth_tracing::FileWorkerGuard;
|
||||
use std::{
|
||||
fmt::{self},
|
||||
|
||||
@ -1,9 +1,9 @@
|
||||
use crate::{hardforks::HlHardforks, node::HlNode, HlBlock, HlBlockBody, HlPrimitives};
|
||||
use crate::{HlBlock, HlBlockBody, HlPrimitives, hardforks::HlHardforks, node::HlNode};
|
||||
use alloy_consensus::Header;
|
||||
use reth::{
|
||||
api::{FullNodeTypes, NodeTypes},
|
||||
beacon_consensus::EthBeaconConsensus,
|
||||
builder::{components::ConsensusBuilder, BuilderContext},
|
||||
builder::{BuilderContext, components::ConsensusBuilder},
|
||||
consensus::{Consensus, ConsensusError, FullConsensus, HeaderValidator},
|
||||
consensus_common::validation::{
|
||||
validate_against_parent_4844, validate_against_parent_hash_number,
|
||||
|
||||
@ -1,11 +1,11 @@
|
||||
//! Copy of reth codebase.
|
||||
|
||||
use alloy_consensus::{proofs::calculate_receipt_root, BlockHeader, TxReceipt};
|
||||
use alloy_consensus::{BlockHeader, TxReceipt, proofs::calculate_receipt_root};
|
||||
use alloy_eips::eip7685::Requests;
|
||||
use alloy_primitives::{Bloom, B256};
|
||||
use alloy_primitives::{B256, Bloom};
|
||||
use reth::consensus::ConsensusError;
|
||||
use reth_chainspec::EthereumHardforks;
|
||||
use reth_primitives::{gas_spent_by_transactions, GotExpected, RecoveredBlock};
|
||||
use reth_primitives::{GotExpected, RecoveredBlock, gas_spent_by_transactions};
|
||||
use reth_primitives_traits::{Block, Receipt as ReceiptTrait};
|
||||
|
||||
pub fn validate_block_post_execution<B, R, ChainSpec>(
|
||||
|
||||
@ -1,6 +1,6 @@
|
||||
use crate::{
|
||||
node::evm::config::{HlBlockExecutorFactory, HlEvmConfig},
|
||||
HlBlock,
|
||||
node::evm::config::{HlBlockExecutorFactory, HlEvmConfig},
|
||||
};
|
||||
use alloy_consensus::Header;
|
||||
use reth_evm::{
|
||||
|
||||
@ -1,5 +1,6 @@
|
||||
use super::{executor::HlBlockExecutor, factory::HlEvmFactory};
|
||||
use crate::{
|
||||
HlBlock, HlBlockBody, HlPrimitives,
|
||||
chainspec::HlChainSpec,
|
||||
evm::{spec::HlSpecId, transaction::HlTxEnv},
|
||||
hardforks::HlHardforks,
|
||||
@ -9,31 +10,30 @@ use crate::{
|
||||
rpc::engine_api::validator::HlExecutionData,
|
||||
types::HlExtras,
|
||||
},
|
||||
HlBlock, HlBlockBody, HlPrimitives,
|
||||
};
|
||||
use alloy_consensus::{BlockHeader, Header, Transaction as _, TxReceipt, EMPTY_OMMER_ROOT_HASH};
|
||||
use alloy_eips::{merge::BEACON_NONCE, Encodable2718};
|
||||
use alloy_consensus::{BlockHeader, EMPTY_OMMER_ROOT_HASH, Header, Transaction as _, TxReceipt};
|
||||
use alloy_eips::{Encodable2718, merge::BEACON_NONCE};
|
||||
use alloy_primitives::{Log, U256};
|
||||
use reth_chainspec::{EthChainSpec, EthereumHardforks, Hardforks};
|
||||
use reth_evm::{
|
||||
block::{BlockExecutionError, BlockExecutorFactory, BlockExecutorFor},
|
||||
eth::{receipt_builder::ReceiptBuilder, EthBlockExecutionCtx},
|
||||
execute::{BlockAssembler, BlockAssemblerInput},
|
||||
precompiles::PrecompilesMap,
|
||||
ConfigureEngineEvm, ConfigureEvm, EvmEnv, EvmEnvFor, EvmFactory, ExecutableTxIterator,
|
||||
ExecutionCtxFor, FromRecoveredTx, FromTxWithEncoded, IntoTxEnv, NextBlockEnvAttributes,
|
||||
block::{BlockExecutionError, BlockExecutorFactory, BlockExecutorFor},
|
||||
eth::{EthBlockExecutionCtx, receipt_builder::ReceiptBuilder},
|
||||
execute::{BlockAssembler, BlockAssemblerInput},
|
||||
precompiles::PrecompilesMap,
|
||||
};
|
||||
use reth_evm_ethereum::EthBlockAssembler;
|
||||
use reth_payload_primitives::NewPayloadError;
|
||||
use reth_primitives::{logs_bloom, BlockTy, HeaderTy, Receipt, SealedBlock, SealedHeader};
|
||||
use reth_primitives_traits::{proofs, SignerRecoverable, WithEncoded};
|
||||
use reth_primitives::{BlockTy, HeaderTy, Receipt, SealedBlock, SealedHeader, logs_bloom};
|
||||
use reth_primitives_traits::{SignerRecoverable, WithEncoded, proofs};
|
||||
use reth_provider::BlockExecutionResult;
|
||||
use reth_revm::State;
|
||||
use revm::{
|
||||
Inspector,
|
||||
context::{BlockEnv, CfgEnv, TxEnv},
|
||||
context_interface::block::BlobExcessGasAndPrice,
|
||||
primitives::hardfork::SpecId,
|
||||
Inspector,
|
||||
};
|
||||
use std::{borrow::Cow, convert::Infallible, sync::Arc};
|
||||
|
||||
@ -45,10 +45,10 @@ pub struct HlBlockAssembler {
|
||||
impl<F> BlockAssembler<F> for HlBlockAssembler
|
||||
where
|
||||
F: for<'a> BlockExecutorFactory<
|
||||
ExecutionCtx<'a> = HlBlockExecutionCtx<'a>,
|
||||
Transaction = TransactionSigned,
|
||||
Receipt = Receipt,
|
||||
>,
|
||||
ExecutionCtx<'a> = HlBlockExecutionCtx<'a>,
|
||||
Transaction = TransactionSigned,
|
||||
Receipt = Receipt,
|
||||
>,
|
||||
{
|
||||
type Block = HlBlock;
|
||||
|
||||
@ -240,9 +240,9 @@ where
|
||||
R: ReceiptBuilder<Transaction = TransactionSigned, Receipt: TxReceipt<Log = Log>>,
|
||||
Spec: EthereumHardforks + HlHardforks + EthChainSpec + Hardforks + Clone,
|
||||
EvmF: EvmFactory<
|
||||
Tx: FromRecoveredTx<TransactionSigned> + FromTxWithEncoded<TransactionSigned>,
|
||||
Precompiles = PrecompilesMap,
|
||||
>,
|
||||
Tx: FromRecoveredTx<TransactionSigned> + FromTxWithEncoded<TransactionSigned>,
|
||||
Precompiles = PrecompilesMap,
|
||||
>,
|
||||
R::Transaction: From<TransactionSigned> + Clone,
|
||||
Self: 'static,
|
||||
HlTxEnv<TxEnv>: IntoTxEnv<<EvmF as EvmFactory>::Tx>,
|
||||
|
||||
@ -7,16 +7,16 @@ use crate::evm::{
|
||||
spec::HlSpecId,
|
||||
transaction::HlTxEnv,
|
||||
};
|
||||
use reth_evm::{precompiles::PrecompilesMap, Database, EvmEnv, EvmFactory};
|
||||
use reth_evm::{Database, EvmEnv, EvmFactory, precompiles::PrecompilesMap};
|
||||
use reth_revm::Context;
|
||||
use revm::{
|
||||
Inspector,
|
||||
context::{
|
||||
result::{EVMError, HaltReason},
|
||||
TxEnv,
|
||||
result::{EVMError, HaltReason},
|
||||
},
|
||||
inspector::NoOpInspector,
|
||||
precompile::{PrecompileSpecId, Precompiles},
|
||||
Inspector,
|
||||
};
|
||||
|
||||
/// Factory producing [`HlEvm`].
|
||||
|
||||
@ -1,6 +1,6 @@
|
||||
use crate::{
|
||||
evm::{
|
||||
api::{ctx::HlContext, HlEvmInner},
|
||||
api::{HlEvmInner, ctx::HlContext},
|
||||
spec::HlSpecId,
|
||||
transaction::HlTxEnv,
|
||||
},
|
||||
@ -10,18 +10,18 @@ use alloy_primitives::{Address, Bytes};
|
||||
use config::HlEvmConfig;
|
||||
use reth::{
|
||||
api::FullNodeTypes,
|
||||
builder::{components::ExecutorBuilder, BuilderContext},
|
||||
builder::{BuilderContext, components::ExecutorBuilder},
|
||||
};
|
||||
use reth_evm::{Database, Evm, EvmEnv};
|
||||
use revm::{
|
||||
context::{
|
||||
result::{EVMError, ExecutionResult, HaltReason, Output, ResultAndState, SuccessReason},
|
||||
BlockEnv, TxEnv,
|
||||
},
|
||||
handler::{instructions::EthInstructions, EthPrecompiles, PrecompileProvider},
|
||||
interpreter::{interpreter::EthInterpreter, InterpreterResult},
|
||||
state::EvmState,
|
||||
Context, ExecuteEvm, InspectEvm, Inspector,
|
||||
context::{
|
||||
BlockEnv, TxEnv,
|
||||
result::{EVMError, ExecutionResult, HaltReason, Output, ResultAndState, SuccessReason},
|
||||
},
|
||||
handler::{EthPrecompiles, PrecompileProvider, instructions::EthInstructions},
|
||||
interpreter::{InterpreterResult, interpreter::EthInterpreter},
|
||||
state::EvmState,
|
||||
};
|
||||
use std::ops::{Deref, DerefMut};
|
||||
|
||||
@ -98,11 +98,7 @@ where
|
||||
&mut self,
|
||||
tx: Self::Tx,
|
||||
) -> Result<ResultAndState<Self::HaltReason>, Self::Error> {
|
||||
if self.inspect {
|
||||
self.inner.inspect_tx(tx)
|
||||
} else {
|
||||
self.inner.transact(tx)
|
||||
}
|
||||
if self.inspect { self.inner.inspect_tx(tx) } else { self.inner.transact(tx) }
|
||||
}
|
||||
|
||||
fn transact_system_call(
|
||||
|
||||
@ -1,4 +1,4 @@
|
||||
use alloy_primitives::{address, Address};
|
||||
use alloy_primitives::{Address, address};
|
||||
use reth_evm::block::BlockExecutionError;
|
||||
use revm::{primitives::HashMap, state::Account};
|
||||
|
||||
|
||||
@ -4,11 +4,11 @@ use crate::{
|
||||
pool::HlPoolBuilder,
|
||||
primitives::{HlBlock, HlPrimitives},
|
||||
rpc::{
|
||||
HlEthApiBuilder,
|
||||
engine_api::{
|
||||
builder::HlEngineApiBuilder, payload::HlPayloadTypes,
|
||||
validator::HlPayloadValidatorBuilder,
|
||||
},
|
||||
HlEthApiBuilder,
|
||||
},
|
||||
storage::HlStorage,
|
||||
},
|
||||
@ -20,14 +20,14 @@ use network::HlNetworkBuilder;
|
||||
use reth::{
|
||||
api::{FullNodeTypes, NodeTypes},
|
||||
builder::{
|
||||
Node, NodeAdapter,
|
||||
components::{ComponentsBuilder, NoopPayloadServiceBuilder},
|
||||
rpc::RpcAddOns,
|
||||
Node, NodeAdapter,
|
||||
},
|
||||
};
|
||||
use reth_engine_primitives::ConsensusEngineHandle;
|
||||
use std::{marker::PhantomData, sync::Arc};
|
||||
use tokio::sync::{oneshot, Mutex};
|
||||
use tokio::sync::{Mutex, oneshot};
|
||||
|
||||
pub mod cli;
|
||||
pub mod consensus;
|
||||
|
||||
@ -8,7 +8,7 @@ use reth_primitives::NodePrimitives;
|
||||
use service::{BlockMsg, ImportEvent, Outcome};
|
||||
use std::{
|
||||
fmt,
|
||||
task::{ready, Context, Poll},
|
||||
task::{Context, Poll, ready},
|
||||
};
|
||||
|
||||
use crate::node::network::HlNewBlock;
|
||||
|
||||
@ -1,17 +1,17 @@
|
||||
use super::handle::ImportHandle;
|
||||
use crate::{
|
||||
HlBlock, HlBlockBody,
|
||||
consensus::HlConsensus,
|
||||
node::{
|
||||
network::HlNewBlock,
|
||||
rpc::engine_api::payload::HlPayloadTypes,
|
||||
types::{BlockAndReceipts, EvmBlock},
|
||||
},
|
||||
HlBlock, HlBlockBody,
|
||||
};
|
||||
use alloy_consensus::{BlockBody, Header};
|
||||
use alloy_primitives::U128;
|
||||
use alloy_rpc_types::engine::{ForkchoiceState, PayloadStatusEnum};
|
||||
use futures::{future::Either, stream::FuturesUnordered, StreamExt};
|
||||
use futures::{StreamExt, future::Either, stream::FuturesUnordered};
|
||||
use reth_engine_primitives::{ConsensusEngineHandle, EngineTypes};
|
||||
use reth_eth_wire::NewBlock;
|
||||
use reth_network::{
|
||||
|
||||
@ -1,20 +1,20 @@
|
||||
#![allow(clippy::owned_cow)]
|
||||
use crate::{
|
||||
HlBlock,
|
||||
consensus::HlConsensus,
|
||||
node::{
|
||||
network::block_import::{handle::ImportHandle, service::ImportService, HlBlockImport},
|
||||
HlNode,
|
||||
network::block_import::{HlBlockImport, handle::ImportHandle, service::ImportService},
|
||||
primitives::HlPrimitives,
|
||||
rpc::engine_api::payload::HlPayloadTypes,
|
||||
types::ReadPrecompileCalls,
|
||||
HlNode,
|
||||
},
|
||||
pseudo_peer::{start_pseudo_peer, BlockSourceConfig},
|
||||
HlBlock,
|
||||
pseudo_peer::{BlockSourceConfig, start_pseudo_peer},
|
||||
};
|
||||
use alloy_rlp::{Decodable, Encodable};
|
||||
use reth::{
|
||||
api::{FullNodeTypes, TxTy},
|
||||
builder::{components::NetworkBuilder, BuilderContext},
|
||||
builder::{BuilderContext, components::NetworkBuilder},
|
||||
transaction_pool::{PoolTransaction, TransactionPool},
|
||||
};
|
||||
use reth_discv4::NodeRecord;
|
||||
@ -26,7 +26,7 @@ use reth_network_api::PeersInfo;
|
||||
use reth_provider::StageCheckpointReader;
|
||||
use reth_stages_types::StageId;
|
||||
use std::sync::Arc;
|
||||
use tokio::sync::{mpsc, oneshot, Mutex};
|
||||
use tokio::sync::{Mutex, mpsc, oneshot};
|
||||
use tracing::info;
|
||||
|
||||
pub mod block_import;
|
||||
@ -38,8 +38,8 @@ pub struct HlNewBlock(pub NewBlock<HlBlock>);
|
||||
mod rlp {
|
||||
use super::*;
|
||||
use crate::{
|
||||
node::primitives::{BlockBody, TransactionSigned},
|
||||
HlBlockBody,
|
||||
node::primitives::{BlockBody, TransactionSigned},
|
||||
};
|
||||
use alloy_consensus::{BlobTransactionSidecar, Header};
|
||||
use alloy_primitives::{Address, U128};
|
||||
|
||||
@ -6,12 +6,12 @@
|
||||
//! Ethereum transaction pool only supports TransactionSigned (EthereumTxEnvelope<TxEip4844>),
|
||||
//! hence this placeholder for the transaction pool.
|
||||
|
||||
use crate::node::{primitives::TransactionSigned, HlNode};
|
||||
use crate::node::{HlNode, primitives::TransactionSigned};
|
||||
use alloy_consensus::{
|
||||
error::ValueError, EthereumTxEnvelope, Transaction as TransactionTrait, TxEip4844,
|
||||
EthereumTxEnvelope, Transaction as TransactionTrait, TxEip4844, error::ValueError,
|
||||
};
|
||||
use alloy_eips::{eip7702::SignedAuthorization, Typed2718};
|
||||
use alloy_primitives::{Address, Bytes, ChainId, TxHash, TxKind, B256, U256};
|
||||
use alloy_eips::{Typed2718, eip7702::SignedAuthorization};
|
||||
use alloy_primitives::{Address, B256, Bytes, ChainId, TxHash, TxKind, U256};
|
||||
use alloy_rpc_types::AccessList;
|
||||
use reth::{
|
||||
api::FullNodeTypes, builder::components::PoolBuilder, transaction_pool::PoolTransaction,
|
||||
@ -19,7 +19,7 @@ use reth::{
|
||||
use reth_ethereum_primitives::PooledTransactionVariant;
|
||||
use reth_primitives::Recovered;
|
||||
use reth_primitives_traits::InMemorySize;
|
||||
use reth_transaction_pool::{noop::NoopTransactionPool, EthPoolTransaction};
|
||||
use reth_transaction_pool::{EthPoolTransaction, noop::NoopTransactionPool};
|
||||
use std::sync::Arc;
|
||||
|
||||
pub struct HlPoolBuilder;
|
||||
|
||||
@ -1,19 +1,19 @@
|
||||
use core::fmt;
|
||||
|
||||
use super::{HlEthApi, HlRpcNodeCore};
|
||||
use crate::{node::evm::apply_precompiles, HlBlock};
|
||||
use alloy_evm::Evm;
|
||||
use crate::{HlBlock, node::evm::apply_precompiles};
|
||||
use alloy_consensus::transaction::TxHashRef;
|
||||
use alloy_evm::Evm;
|
||||
use alloy_primitives::B256;
|
||||
use reth::rpc::server_types::eth::EthApiError;
|
||||
use reth_evm::{ConfigureEvm, Database, EvmEnvFor, HaltReasonFor, InspectorFor, SpecFor, TxEnvFor};
|
||||
use reth_primitives::{NodePrimitives, Recovered};
|
||||
use reth_provider::{ProviderError, ProviderTx};
|
||||
use reth_rpc_eth_api::{
|
||||
helpers::{Call, EthCall},
|
||||
FromEvmError, RpcConvert, RpcNodeCore,
|
||||
helpers::{Call, EthCall},
|
||||
};
|
||||
use revm::{context::result::ResultAndState, DatabaseCommit};
|
||||
use revm::{DatabaseCommit, context::result::ResultAndState};
|
||||
|
||||
impl<N> HlRpcNodeCore for N where N: RpcNodeCore<Primitives: NodePrimitives<Block = HlBlock>> {}
|
||||
|
||||
@ -22,11 +22,11 @@ where
|
||||
N: HlRpcNodeCore,
|
||||
EthApiError: FromEvmError<N::Evm>,
|
||||
Rpc: RpcConvert<
|
||||
Primitives = N::Primitives,
|
||||
Error = EthApiError,
|
||||
TxEnv = TxEnvFor<N::Evm>,
|
||||
Spec = SpecFor<N::Evm>,
|
||||
>,
|
||||
Primitives = N::Primitives,
|
||||
Error = EthApiError,
|
||||
TxEnv = TxEnvFor<N::Evm>,
|
||||
Spec = SpecFor<N::Evm>,
|
||||
>,
|
||||
{
|
||||
}
|
||||
|
||||
@ -35,11 +35,11 @@ where
|
||||
N: HlRpcNodeCore,
|
||||
EthApiError: FromEvmError<N::Evm>,
|
||||
Rpc: RpcConvert<
|
||||
Primitives = N::Primitives,
|
||||
Error = EthApiError,
|
||||
TxEnv = TxEnvFor<N::Evm>,
|
||||
Spec = SpecFor<N::Evm>,
|
||||
>,
|
||||
Primitives = N::Primitives,
|
||||
Error = EthApiError,
|
||||
TxEnv = TxEnvFor<N::Evm>,
|
||||
Spec = SpecFor<N::Evm>,
|
||||
>,
|
||||
{
|
||||
#[inline]
|
||||
fn call_gas_limit(&self) -> u64 {
|
||||
|
||||
@ -9,7 +9,7 @@ use alloy_primitives::B256;
|
||||
use alloy_rpc_types_engine::PayloadError;
|
||||
use reth::{
|
||||
api::{FullNodeComponents, NodeTypes},
|
||||
builder::{rpc::PayloadValidatorBuilder, AddOnsContext},
|
||||
builder::{AddOnsContext, rpc::PayloadValidatorBuilder},
|
||||
};
|
||||
use reth_engine_primitives::{ExecutionPayload, PayloadValidator};
|
||||
use reth_payload_primitives::NewPayloadError;
|
||||
|
||||
@ -1,5 +1,5 @@
|
||||
use super::{apply_precompiles, HlEthApi, HlRpcNodeCore};
|
||||
use alloy_evm::overrides::{apply_state_overrides, StateOverrideError};
|
||||
use super::{HlEthApi, HlRpcNodeCore, apply_precompiles};
|
||||
use alloy_evm::overrides::{StateOverrideError, apply_state_overrides};
|
||||
use alloy_network::TransactionBuilder;
|
||||
use alloy_primitives::{TxKind, U256};
|
||||
use alloy_rpc_types_eth::state::StateOverride;
|
||||
@ -9,19 +9,19 @@ use reth_evm::{ConfigureEvm, Evm, EvmEnvFor, SpecFor, TransactionEnv, TxEnvFor};
|
||||
use reth_revm::{database::StateProviderDatabase, db::CacheDB};
|
||||
use reth_rpc_convert::{RpcConvert, RpcTxReq};
|
||||
use reth_rpc_eth_api::{
|
||||
helpers::{
|
||||
estimate::{update_estimated_gas_range, EstimateCall},
|
||||
Call,
|
||||
},
|
||||
AsEthApiError, IntoEthApiError, RpcNodeCore,
|
||||
helpers::{
|
||||
Call,
|
||||
estimate::{EstimateCall, update_estimated_gas_range},
|
||||
},
|
||||
};
|
||||
use reth_rpc_eth_types::{
|
||||
error::{api::FromEvmHalt, FromEvmError},
|
||||
EthApiError, RevertError, RpcInvalidTransactionError,
|
||||
error::{FromEvmError, api::FromEvmHalt},
|
||||
};
|
||||
use reth_rpc_server_types::constants::gas_oracle::{CALL_STIPEND_GAS, ESTIMATE_GAS_ERROR_RATIO};
|
||||
use reth_storage_api::StateProvider;
|
||||
use revm::context_interface::{result::ExecutionResult, Transaction};
|
||||
use revm::context_interface::{Transaction, result::ExecutionResult};
|
||||
use tracing::trace;
|
||||
|
||||
impl<N, Rpc> EstimateCall for HlEthApi<N, Rpc>
|
||||
@ -30,11 +30,11 @@ where
|
||||
N: HlRpcNodeCore,
|
||||
EthApiError: FromEvmError<N::Evm> + From<StateOverrideError<ProviderError>>,
|
||||
Rpc: RpcConvert<
|
||||
Primitives = N::Primitives,
|
||||
Error = EthApiError,
|
||||
TxEnv = TxEnvFor<N::Evm>,
|
||||
Spec = SpecFor<N::Evm>,
|
||||
>,
|
||||
Primitives = N::Primitives,
|
||||
Error = EthApiError,
|
||||
TxEnv = TxEnvFor<N::Evm>,
|
||||
Spec = SpecFor<N::Evm>,
|
||||
>,
|
||||
{
|
||||
// Modified version that adds `apply_precompiles`; comments are stripped out.
|
||||
fn estimate_gas_with<S>(
|
||||
|
||||
@ -1,6 +1,6 @@
|
||||
use alloy_eips::BlockId;
|
||||
use jsonrpsee::proc_macros::rpc;
|
||||
use jsonrpsee_core::{async_trait, RpcResult};
|
||||
use jsonrpsee_core::{RpcResult, async_trait};
|
||||
use reth_rpc_convert::RpcConvert;
|
||||
use reth_rpc_eth_types::EthApiError;
|
||||
use tracing::trace;
|
||||
|
||||
@ -1,5 +1,5 @@
|
||||
use crate::node::spot_meta::SpotId;
|
||||
use alloy_primitives::{address, Address};
|
||||
use alloy_primitives::{Address, address};
|
||||
use std::collections::BTreeMap;
|
||||
|
||||
/// Testnet-specific fix for #67
|
||||
|
||||
@ -1,22 +1,22 @@
|
||||
use crate::{
|
||||
HlBlock, HlBlockBody, HlPrimitives,
|
||||
node::{
|
||||
primitives::tx_wrapper::{convert_to_eth_block_body, convert_to_hl_block_body},
|
||||
types::HlExtras,
|
||||
},
|
||||
HlBlock, HlBlockBody, HlPrimitives,
|
||||
};
|
||||
use alloy_consensus::BlockHeader;
|
||||
use alloy_primitives::Bytes;
|
||||
use reth_chainspec::EthereumHardforks;
|
||||
use reth_db::{
|
||||
DbTxUnwindExt,
|
||||
cursor::{DbCursorRO, DbCursorRW},
|
||||
transaction::{DbTx, DbTxMut},
|
||||
DbTxUnwindExt,
|
||||
};
|
||||
use reth_provider::{
|
||||
providers::{ChainStorage, NodeTypesForProvider},
|
||||
BlockBodyReader, BlockBodyWriter, ChainSpecProvider, ChainStorageReader, ChainStorageWriter,
|
||||
DBProvider, DatabaseProvider, EthStorage, ProviderResult, ReadBodyInput, StorageLocation,
|
||||
providers::{ChainStorage, NodeTypesForProvider},
|
||||
};
|
||||
|
||||
pub mod tables;
|
||||
|
||||
@ -1,5 +1,5 @@
|
||||
use alloy_primitives::{BlockNumber, Bytes};
|
||||
use reth_db::{table::TableInfo, tables, TableSet, TableType, TableViewer};
|
||||
use reth_db::{TableSet, TableType, TableViewer, table::TableInfo, tables};
|
||||
use std::fmt;
|
||||
|
||||
tables! {
|
||||
|
||||
@ -2,7 +2,7 @@
|
||||
//!
|
||||
//! Changes:
|
||||
//! - ReadPrecompileCalls supports RLP encoding / decoding
|
||||
use alloy_primitives::{Address, Bytes, Log, B256};
|
||||
use alloy_primitives::{Address, B256, Bytes, Log};
|
||||
use alloy_rlp::{Decodable, Encodable, RlpDecodable, RlpEncodable};
|
||||
use bytes::BufMut;
|
||||
use serde::{Deserialize, Serialize};
|
||||
|
||||
@ -10,12 +10,12 @@ use std::{
|
||||
use tracing::info;
|
||||
|
||||
use crate::{
|
||||
HlBlock, HlBlockBody,
|
||||
node::{
|
||||
primitives::TransactionSigned as TxSigned,
|
||||
spot_meta::{erc20_contract_to_spot_token, SpotId},
|
||||
spot_meta::{SpotId, erc20_contract_to_spot_token},
|
||||
types::{ReadPrecompileCalls, SystemTx},
|
||||
},
|
||||
HlBlock, HlBlockBody,
|
||||
};
|
||||
|
||||
/// A raw transaction.
|
||||
|
||||
Reference in New Issue
Block a user