17 Commits

Author SHA1 Message Date
3f08b0a4e6 Merge pull request #55 from hl-archive-node/fix/txenv-on-trace
fix: Fill precompiles when tracing
2025-09-04 20:39:16 -04:00
d7992ab8ff remove: Remove unnecessary trait implementation 2025-09-04 20:38:41 -04:00
b37a30fb37 fix: Fill precompiles in tracing APIs 2025-09-04 20:37:10 -04:00
f6432498d8 refactor: Relax apply_precompiles and expose 2025-09-04 20:37:07 -04:00
772ff250ce Merge pull request #52 from hl-archive-node/fix/avoid-crash-on-eth-failure
fix: Do not crash when collect_block failed
2025-08-29 02:51:10 +09:00
5ee9053286 fix: Do not crash when collect_block failed
Just gracefully return it as error and log it
2025-08-28 13:47:44 -04:00
29e6972d58 Merge pull request #51 from hl-archive-node/feat/no-eth-proof
fix: Disable eth_getProof by default
2025-08-29 02:07:24 +09:00
e87b9232cc fix: Disable eth_getProof by default
No need to give malfunctioning feature by default. Issue #15 affects
StoragesTrie, AccountsTrie table which is used only for state root and
proof generation.
Also clearing the table does not affect any other parts of reth node.

Meanwhile, add --experimental-eth-get-proof flag to enable eth_getProof
forcefully.
2025-08-28 10:27:32 -04:00
b004263f82 Merge pull request #50 from Quertyy/feat/rpc-system-tx-receipts
chore(rpc): add eth_getEvmSystemTxsReceiptsByBlockHash and eth_getEvmSystemTxsReceiptsByBlockHash rpc method
2025-08-28 23:26:05 +09:00
74e27b5ee2 refactor(rpc): extract common logic for getting system txs 2025-08-28 16:10:41 +02:00
09fcf0751f chore(rpc): add eth_getSystemTxsReceiptsByBlockNumber and eth_getSystemTxsReceiptsByBlockNumber rpc method 2025-08-28 15:39:37 +02:00
8f2eca4754 Merge pull request #48 from Quertyy/feat/rpc-block-system-tx
chore(rpc): add eth_getEvmSystemTxsByBlockNumber and eth_getEvmSystemTxsByBlockHash rpc methods
2025-08-28 17:45:43 +09:00
707b4fb709 chore(rpc): return types compliance 2025-08-27 10:34:34 +02:00
62dd5a71b5 chore(rpc): change methods name 2025-08-26 22:03:40 +02:00
412c38a8cd chore(rpc): add eth_getSystemTxsByBlockNumber and eth_getSystemTxsByBlockNumber rpc method 2025-08-26 21:24:28 +02:00
796ea518bd Merge pull request #47 from hl-archive-node/fix/issue-46
fix: Sort hl-node files correctly
2025-08-27 02:49:16 +09:00
dd2c925af2 fix: Sort hl-node files correctly 2025-08-26 13:47:34 -04:00
14 changed files with 410 additions and 69 deletions

View File

@ -7,17 +7,18 @@
//! For non-system transactions, we can just return the log as is, and the client will //! For non-system transactions, we can just return the log as is, and the client will
//! adjust the transaction index accordingly. //! adjust the transaction index accordingly.
use alloy_consensus::{transaction::TransactionMeta, TxReceipt}; use alloy_consensus::{transaction::TransactionMeta, BlockHeader, TxReceipt};
use alloy_eips::{BlockId, BlockNumberOrTag}; use alloy_eips::{BlockId, BlockNumberOrTag};
use alloy_json_rpc::RpcObject; use alloy_json_rpc::RpcObject;
use alloy_primitives::{B256, U256}; use alloy_primitives::{B256, U256};
use alloy_rpc_types::{ use alloy_rpc_types::{
pubsub::{Params, SubscriptionKind}, pubsub::{Params, SubscriptionKind},
BlockTransactions, Filter, FilterChanges, FilterId, Log, PendingTransactionFilterKind, BlockTransactions, Filter, FilterChanges, FilterId, Log, PendingTransactionFilterKind,
TransactionInfo,
}; };
use jsonrpsee::{proc_macros::rpc, PendingSubscriptionSink, SubscriptionMessage, SubscriptionSink}; use jsonrpsee::{proc_macros::rpc, PendingSubscriptionSink, SubscriptionMessage, SubscriptionSink};
use jsonrpsee_core::{async_trait, RpcResult}; use jsonrpsee_core::{async_trait, RpcResult};
use jsonrpsee_types::ErrorObject; use jsonrpsee_types::{error::INTERNAL_ERROR_CODE, ErrorObject};
use reth::{api::FullNodeComponents, builder::rpc::RpcContext, tasks::TaskSpawner}; use reth::{api::FullNodeComponents, builder::rpc::RpcContext, tasks::TaskSpawner};
use reth_primitives_traits::{BlockBody as _, SignedTransaction}; use reth_primitives_traits::{BlockBody as _, SignedTransaction};
use reth_provider::{BlockIdReader, BlockReader, BlockReaderIdExt, ReceiptProvider}; use reth_provider::{BlockIdReader, BlockReader, BlockReaderIdExt, ReceiptProvider};
@ -71,6 +72,217 @@ impl<T> EthWrapper for T where
{ {
} }
#[rpc(server, namespace = "eth")]
#[async_trait]
pub trait EthSystemTransactionApi<T: RpcObject, R: RpcObject> {
#[method(name = "getEvmSystemTxsByBlockHash")]
async fn get_evm_system_txs_by_block_hash(&self, hash: B256) -> RpcResult<Option<Vec<T>>>;
#[method(name = "getEvmSystemTxsByBlockNumber")]
async fn get_evm_system_txs_by_block_number(
&self,
block_id: Option<BlockId>,
) -> RpcResult<Option<Vec<T>>>;
#[method(name = "getEvmSystemTxsReceiptsByBlockHash")]
async fn get_evm_system_txs_receipts_by_block_hash(
&self,
hash: B256,
) -> RpcResult<Option<Vec<R>>>;
#[method(name = "getEvmSystemTxsReceiptsByBlockNumber")]
async fn get_evm_system_txs_receipts_by_block_number(
&self,
block_id: Option<BlockId>,
) -> RpcResult<Option<Vec<R>>>;
}
pub struct HlSystemTransactionExt<Eth: EthWrapper> {
eth_api: Eth,
_marker: PhantomData<Eth>,
}
impl<Eth: EthWrapper> HlSystemTransactionExt<Eth> {
pub fn new(eth_api: Eth) -> Self {
Self { eth_api, _marker: PhantomData }
}
async fn get_system_txs_by_block_id(
&self,
block_id: BlockId,
) -> RpcResult<Option<Vec<RpcTransaction<Eth::NetworkTypes>>>>
where
jsonrpsee_types::ErrorObject<'static>: From<<Eth as EthApiTypes>::Error>,
{
if let Some(block) = self.eth_api.recovered_block(block_id).await? {
let block_hash = block.hash();
let block_number = block.number();
let base_fee_per_gas = block.base_fee_per_gas();
let system_txs = block
.transactions_with_sender()
.enumerate()
.filter_map(|(index, (signer, tx))| {
if tx.is_system_transaction() {
let tx_info = TransactionInfo {
hash: Some(*tx.tx_hash()),
block_hash: Some(block_hash),
block_number: Some(block_number),
base_fee: base_fee_per_gas,
index: Some(index as u64),
};
self.eth_api
.tx_resp_builder()
.fill(tx.clone().with_signer(*signer), tx_info)
.ok()
} else {
None
}
})
.collect();
Ok(Some(system_txs))
} else {
Ok(None)
}
}
async fn get_system_txs_receipts_by_block_id(
&self,
block_id: BlockId,
) -> RpcResult<Option<Vec<RpcReceipt<Eth::NetworkTypes>>>>
where
jsonrpsee_types::ErrorObject<'static>: From<<Eth as EthApiTypes>::Error>,
{
if let Some((block, receipts)) =
EthBlocks::load_block_and_receipts(&self.eth_api, block_id).await?
{
let block_number = block.number;
let base_fee = block.base_fee_per_gas;
let block_hash = block.hash();
let excess_blob_gas = block.excess_blob_gas;
let timestamp = block.timestamp;
let mut gas_used = 0;
let mut next_log_index = 0;
let mut inputs = Vec::new();
for (idx, (tx, receipt)) in
block.transactions_recovered().zip(receipts.iter()).enumerate()
{
if receipt.cumulative_gas_used() != 0 {
break;
}
let meta = TransactionMeta {
tx_hash: *tx.tx_hash(),
index: idx as u64,
block_hash,
block_number,
base_fee,
excess_blob_gas,
timestamp,
};
let input = ConvertReceiptInput {
receipt: Cow::Borrowed(receipt),
tx,
gas_used: receipt.cumulative_gas_used() - gas_used,
next_log_index,
meta,
};
gas_used = receipt.cumulative_gas_used();
next_log_index += receipt.logs().len();
inputs.push(input);
}
let receipts = self.eth_api.tx_resp_builder().convert_receipts(inputs)?;
Ok(Some(receipts))
} else {
Ok(None)
}
}
}
#[async_trait]
impl<Eth: EthWrapper>
EthSystemTransactionApiServer<RpcTransaction<Eth::NetworkTypes>, RpcReceipt<Eth::NetworkTypes>>
for HlSystemTransactionExt<Eth>
where
jsonrpsee_types::ErrorObject<'static>: From<<Eth as EthApiTypes>::Error>,
{
/// Returns the system transactions for a given block hash.
/// Semi-compliance with the `eth_getSystemTxsByBlockHash` RPC method introduced by hl-node.
/// https://hyperliquid.gitbook.io/hyperliquid-docs/for-developers/hyperevm/json-rpc
///
/// NOTE: Method name differs from hl-node because we retrieve transaction data from EVM
/// (signature recovery for 'from' address, EVM hash calculation) rather than HyperCore.
async fn get_evm_system_txs_by_block_hash(
&self,
hash: B256,
) -> RpcResult<Option<Vec<RpcTransaction<Eth::NetworkTypes>>>> {
trace!(target: "rpc::eth", ?hash, "Serving eth_getEvmSystemTxsByBlockHash");
match self.get_system_txs_by_block_id(BlockId::Hash(hash.into())).await {
Ok(txs) => Ok(txs),
// hl-node returns none if the block is not found
Err(_) => Ok(None),
}
}
/// Returns the system transactions for a given block number, or the latest block if no block
/// number is provided. Semi-compliance with the `eth_getSystemTxsByBlockNumber` RPC method
/// introduced by hl-node. https://hyperliquid.gitbook.io/hyperliquid-docs/for-developers/hyperevm/json-rpc
///
/// NOTE: Method name differs from hl-node because we retrieve transaction data from EVM
/// (signature recovery for 'from' address, EVM hash calculation) rather than HyperCore.
async fn get_evm_system_txs_by_block_number(
&self,
id: Option<BlockId>,
) -> RpcResult<Option<Vec<RpcTransaction<Eth::NetworkTypes>>>> {
trace!(target: "rpc::eth", ?id, "Serving eth_getEvmSystemTxsByBlockNumber");
match self.get_system_txs_by_block_id(id.unwrap_or_default()).await? {
Some(txs) => Ok(Some(txs)),
None => {
// hl-node returns an error if the block is not found
Err(ErrorObject::owned(
INTERNAL_ERROR_CODE,
format!("invalid block height: {id:?}"),
Some(()),
))
}
}
}
/// Returns the receipts for the system transactions for a given block hash.
async fn get_evm_system_txs_receipts_by_block_hash(
&self,
hash: B256,
) -> RpcResult<Option<Vec<RpcReceipt<Eth::NetworkTypes>>>> {
trace!(target: "rpc::eth", ?hash, "Serving eth_getEvmSystemTxsReceiptsByBlockHash");
match self.get_system_txs_receipts_by_block_id(BlockId::Hash(hash.into())).await {
Ok(receipts) => Ok(receipts),
// hl-node returns none if the block is not found
Err(_) => Ok(None),
}
}
/// Returns the receipts for the system transactions for a given block number, or the latest
/// block if no block
async fn get_evm_system_txs_receipts_by_block_number(
&self,
block_id: Option<BlockId>,
) -> RpcResult<Option<Vec<RpcReceipt<Eth::NetworkTypes>>>> {
trace!(target: "rpc::eth", ?block_id, "Serving eth_getEvmSystemTxsReceiptsByBlockNumber");
match self.get_system_txs_receipts_by_block_id(block_id.unwrap_or_default()).await? {
Some(receipts) => Ok(Some(receipts)),
None => Err(ErrorObject::owned(
INTERNAL_ERROR_CODE,
format!("invalid block height: {block_id:?}"),
Some(()),
)),
}
}
}
pub struct HlNodeFilterHttp<Eth: EthWrapper> { pub struct HlNodeFilterHttp<Eth: EthWrapper> {
filter: Arc<EthFilter<Eth>>, filter: Arc<EthFilter<Eth>>,
provider: Arc<Eth::Provider>, provider: Arc<Eth::Provider>,
@ -146,8 +358,9 @@ impl<Eth: EthWrapper> HlNodeFilterWs<Eth> {
} }
#[async_trait] #[async_trait]
impl<Eth: EthWrapper> EthPubSubApiServer<RpcTransaction<Eth::NetworkTypes>> impl<Eth: EthWrapper> EthPubSubApiServer<RpcTransaction<Eth::NetworkTypes>> for HlNodeFilterWs<Eth>
for HlNodeFilterWs<Eth> where
jsonrpsee_types::error::ErrorObject<'static>: From<<Eth as EthApiTypes>::Error>,
{ {
async fn subscribe( async fn subscribe(
&self, &self,
@ -446,7 +659,7 @@ where
} }
pub fn install_hl_node_compliance<Node, EthApi>( pub fn install_hl_node_compliance<Node, EthApi>(
ctx: RpcContext<Node, EthApi>, ctx: &mut RpcContext<Node, EthApi>,
) -> Result<(), eyre::Error> ) -> Result<(), eyre::Error>
where where
Node: FullNodeComponents, Node: FullNodeComponents,
@ -473,5 +686,9 @@ where
ctx.modules.replace_configured( ctx.modules.replace_configured(
HlNodeBlockFilterHttp::new(Arc::new(ctx.registry.eth_api().clone())).into_rpc(), HlNodeBlockFilterHttp::new(Arc::new(ctx.registry.eth_api().clone())).into_rpc(),
)?; )?;
ctx.modules
.merge_configured(HlSystemTransactionExt::new(ctx.registry.eth_api().clone()).into_rpc())?;
Ok(()) Ok(())
} }

View File

@ -39,7 +39,7 @@ fn main() -> eyre::Result<()> {
let (node, engine_handle_tx) = HlNode::new(ext.block_source_args.parse().await?); let (node, engine_handle_tx) = HlNode::new(ext.block_source_args.parse().await?);
let NodeHandle { node, node_exit_future: exit_future } = builder let NodeHandle { node, node_exit_future: exit_future } = builder
.node(node) .node(node)
.extend_rpc_modules(move |ctx| { .extend_rpc_modules(move |mut ctx| {
let upstream_rpc_url = let upstream_rpc_url =
ext.upstream_rpc_url.unwrap_or_else(|| default_upstream_rpc_url.to_owned()); ext.upstream_rpc_url.unwrap_or_else(|| default_upstream_rpc_url.to_owned());
@ -60,10 +60,15 @@ fn main() -> eyre::Result<()> {
} }
if ext.hl_node_compliant { if ext.hl_node_compliant {
install_hl_node_compliance(ctx)?; install_hl_node_compliance(&mut ctx)?;
info!("hl-node compliant mode enabled"); info!("hl-node compliant mode enabled");
} }
if !ext.experimental_eth_get_proof {
ctx.modules.remove_method_from_configured("eth_getProof");
info!("eth_getProof is disabled by default");
}
Ok(()) Ok(())
}) })
.apply(|builder| { .apply(|builder| {

View File

@ -55,6 +55,24 @@ pub struct HlNodeArgs {
/// This is useful when read precompile is needed for gas estimation. /// This is useful when read precompile is needed for gas estimation.
#[arg(long, env = "FORWARD_CALL")] #[arg(long, env = "FORWARD_CALL")]
pub forward_call: bool, pub forward_call: bool,
/// Experimental: enables the eth_getProof RPC method.
///
/// Note: Due to the state root difference, trie updates* may not function correctly in all
/// scenarios. For example, incremental root updates are not possible, which can cause
/// eth_getProof to malfunction in some cases.
///
/// This limitation does not impact normal node functionality, except for state root (which is
/// unused) and eth_getProof. The archival state is maintained by block order, not by trie
/// updates. As a precaution, nanoreth disables eth_getProof by default to prevent
/// potential issues.
///
/// Use --experimental-eth-get-proof to forcibly enable eth_getProof, assuming trie updates are
/// working as intended. Enabling this by default will be tracked in #15.
///
/// * Refers to the Merkle trie used for eth_getProof and state root, not actual state values.
#[arg(long, env = "EXPERIMENTAL_ETH_GET_PROOF")]
pub experimental_eth_get_proof: bool,
} }
/// The main reth_hl cli interface. /// The main reth_hl cli interface.

View File

@ -4,7 +4,7 @@ use crate::{
hardforks::HlHardforks, hardforks::HlHardforks,
node::{ node::{
primitives::TransactionSigned, primitives::TransactionSigned,
types::{ReadPrecompileInput, ReadPrecompileResult}, types::{HlExtras, ReadPrecompileInput, ReadPrecompileResult},
}, },
}; };
use alloy_consensus::{Transaction, TxReceipt}; use alloy_consensus::{Transaction, TxReceipt};
@ -102,7 +102,7 @@ where
{ {
/// Creates a new HlBlockExecutor. /// Creates a new HlBlockExecutor.
pub fn new(mut evm: EVM, ctx: HlBlockExecutionCtx<'a>, spec: Spec, receipt_builder: R) -> Self { pub fn new(mut evm: EVM, ctx: HlBlockExecutionCtx<'a>, spec: Spec, receipt_builder: R) -> Self {
apply_precompiles(&mut evm, &ctx); apply_precompiles(&mut evm, &ctx.extras);
Self { spec, evm, gas_used: 0, receipts: vec![], receipt_builder, ctx } Self { spec, evm, gas_used: 0, receipts: vec![], receipt_builder, ctx }
} }
@ -155,7 +155,7 @@ where
type Evm = E; type Evm = E;
fn apply_pre_execution_changes(&mut self) -> Result<(), BlockExecutionError> { fn apply_pre_execution_changes(&mut self) -> Result<(), BlockExecutionError> {
apply_precompiles(&mut self.evm, &self.ctx); apply_precompiles(&mut self.evm, &self.ctx.extras);
self.deploy_corewriter_contract()?; self.deploy_corewriter_contract()?;
Ok(()) Ok(())
@ -240,10 +240,9 @@ where
} }
} }
fn apply_precompiles<'a, DB, EVM>(evm: &mut EVM, ctx: &HlBlockExecutionCtx<'a>) pub fn apply_precompiles<EVM>(evm: &mut EVM, extras: &HlExtras)
where where
EVM: Evm<DB = &'a mut State<DB>, Precompiles = PrecompilesMap>, EVM: Evm<Precompiles = PrecompilesMap>,
DB: Database + 'a,
{ {
let block_number = evm.block().number; let block_number = evm.block().number;
let precompiles_mut = evm.precompiles_mut(); let precompiles_mut = evm.precompiles_mut();
@ -255,9 +254,7 @@ where
precompiles_mut.apply_precompile(&address, |_| None); precompiles_mut.apply_precompile(&address, |_| None);
} }
} }
for (address, precompile) in for (address, precompile) in extras.read_precompile_calls.clone().unwrap_or_default().0.iter() {
ctx.extras.read_precompile_calls.clone().unwrap_or_default().0.iter()
{
let precompile = precompile.clone(); let precompile = precompile.clone();
precompiles_mut.apply_precompile(address, |_| { precompiles_mut.apply_precompile(address, |_| {
let precompiles_map: HashMap<ReadPrecompileInput, ReadPrecompileResult> = let precompiles_map: HashMap<ReadPrecompileInput, ReadPrecompileResult> =
@ -271,7 +268,7 @@ where
// NOTE: This is adapted from hyperliquid-dex/hyper-evm-sync#5 // NOTE: This is adapted from hyperliquid-dex/hyper-evm-sync#5
const WARM_PRECOMPILES_BLOCK_NUMBER: u64 = 8_197_684; const WARM_PRECOMPILES_BLOCK_NUMBER: u64 = 8_197_684;
if block_number >= U256::from(WARM_PRECOMPILES_BLOCK_NUMBER) { if block_number >= U256::from(WARM_PRECOMPILES_BLOCK_NUMBER) {
fill_all_precompiles(ctx, precompiles_mut); fill_all_precompiles(extras, precompiles_mut);
} }
} }
@ -279,9 +276,9 @@ fn address_to_u64(address: Address) -> u64 {
address.into_u256().try_into().unwrap() address.into_u256().try_into().unwrap()
} }
fn fill_all_precompiles<'a>(ctx: &HlBlockExecutionCtx<'a>, precompiles_mut: &mut PrecompilesMap) { fn fill_all_precompiles(extras: &HlExtras, precompiles_mut: &mut PrecompilesMap) {
let lowest_address = 0x800; let lowest_address = 0x800;
let highest_address = ctx.extras.highest_precompile_address.map_or(0x80D, address_to_u64); let highest_address = extras.highest_precompile_address.map_or(0x80D, address_to_u64);
for address in lowest_address..=highest_address { for address in lowest_address..=highest_address {
let address = Address::from(U160::from(address)); let address = Address::from(U160::from(address));
precompiles_mut.apply_precompile(&address, |f| { precompiles_mut.apply_precompile(&address, |f| {

View File

@ -32,6 +32,8 @@ mod factory;
mod patch; mod patch;
pub mod receipt_builder; pub mod receipt_builder;
pub use executor::apply_precompiles;
/// HL EVM implementation. /// HL EVM implementation.
/// ///
/// This is a wrapper type around the `revm` evm with optional [`Inspector`] (tracing) /// This is a wrapper type around the `revm` evm with optional [`Inspector`] (tracing)

View File

@ -212,10 +212,6 @@ impl From<EthereumTxEnvelope<TxEip4844WithSidecar<BlobTransactionSidecarVariant>
impl Compress for TransactionSigned { impl Compress for TransactionSigned {
type Compressed = Vec<u8>; type Compressed = Vec<u8>;
fn compress(self) -> Self::Compressed {
self.into_inner().compress()
}
fn compress_to_buf<B: bytes::BufMut + AsMut<[u8]>>(&self, buf: &mut B) { fn compress_to_buf<B: bytes::BufMut + AsMut<[u8]>>(&self, buf: &mut B) {
self.inner().compress_to_buf(buf); self.inner().compress_to_buf(buf);
} }

View File

@ -1,4 +1,4 @@
use crate::node::rpc::HlEthApi; use crate::node::rpc::{HlEthApi, HlRpcNodeCore};
use reth::rpc::server_types::eth::{ use reth::rpc::server_types::eth::{
builder::config::PendingBlockKind, error::FromEvmError, EthApiError, PendingBlock, builder::config::PendingBlockKind, error::FromEvmError, EthApiError, PendingBlock,
}; };
@ -6,12 +6,12 @@ use reth_rpc_eth_api::{
helpers::{ helpers::{
pending_block::PendingEnvBuilder, EthBlocks, LoadBlock, LoadPendingBlock, LoadReceipt, pending_block::PendingEnvBuilder, EthBlocks, LoadBlock, LoadPendingBlock, LoadReceipt,
}, },
RpcConvert, RpcNodeCore, RpcConvert,
}; };
impl<N, Rpc> EthBlocks for HlEthApi<N, Rpc> impl<N, Rpc> EthBlocks for HlEthApi<N, Rpc>
where where
N: RpcNodeCore, N: HlRpcNodeCore,
EthApiError: FromEvmError<N::Evm>, EthApiError: FromEvmError<N::Evm>,
Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError>, Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError>,
{ {
@ -19,7 +19,7 @@ where
impl<N, Rpc> LoadBlock for HlEthApi<N, Rpc> impl<N, Rpc> LoadBlock for HlEthApi<N, Rpc>
where where
N: RpcNodeCore, N: HlRpcNodeCore,
EthApiError: FromEvmError<N::Evm>, EthApiError: FromEvmError<N::Evm>,
Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError>, Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError>,
{ {
@ -27,7 +27,7 @@ where
impl<N, Rpc> LoadPendingBlock for HlEthApi<N, Rpc> impl<N, Rpc> LoadPendingBlock for HlEthApi<N, Rpc>
where where
N: RpcNodeCore, N: HlRpcNodeCore,
EthApiError: FromEvmError<N::Evm>, EthApiError: FromEvmError<N::Evm>,
Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError>, Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError>,
{ {
@ -49,7 +49,7 @@ where
impl<N, Rpc> LoadReceipt for HlEthApi<N, Rpc> impl<N, Rpc> LoadReceipt for HlEthApi<N, Rpc>
where where
N: RpcNodeCore, N: HlRpcNodeCore,
EthApiError: FromEvmError<N::Evm>, EthApiError: FromEvmError<N::Evm>,
Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError>, Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError>,
{ {

View File

@ -1,14 +1,23 @@
use super::HlEthApi; use super::{HlEthApi, HlRpcNodeCore};
use crate::{node::evm::apply_precompiles, HlBlock};
use alloy_evm::Evm;
use alloy_primitives::B256;
use reth::rpc::server_types::eth::EthApiError; use reth::rpc::server_types::eth::EthApiError;
use reth_evm::TxEnvFor; use reth_evm::{ConfigureEvm, Database, EvmEnvFor, TxEnvFor};
use reth_primitives::{NodePrimitives, Recovered};
use reth_primitives_traits::SignedTransaction;
use reth_provider::{ProviderError, ProviderTx};
use reth_rpc_eth_api::{ use reth_rpc_eth_api::{
helpers::{estimate::EstimateCall, Call, EthCall}, helpers::{estimate::EstimateCall, Call, EthCall},
FromEvmError, RpcConvert, RpcNodeCore, FromEvmError, RpcConvert, RpcNodeCore,
}; };
use revm::DatabaseCommit;
impl<N> HlRpcNodeCore for N where N: RpcNodeCore<Primitives: NodePrimitives<Block = HlBlock>> {}
impl<N, Rpc> EthCall for HlEthApi<N, Rpc> impl<N, Rpc> EthCall for HlEthApi<N, Rpc>
where where
N: RpcNodeCore, N: HlRpcNodeCore,
EthApiError: FromEvmError<N::Evm>, EthApiError: FromEvmError<N::Evm>,
Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError, TxEnv = TxEnvFor<N::Evm>>, Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError, TxEnv = TxEnvFor<N::Evm>>,
{ {
@ -16,7 +25,7 @@ where
impl<N, Rpc> EstimateCall for HlEthApi<N, Rpc> impl<N, Rpc> EstimateCall for HlEthApi<N, Rpc>
where where
N: RpcNodeCore, N: HlRpcNodeCore,
EthApiError: FromEvmError<N::Evm>, EthApiError: FromEvmError<N::Evm>,
Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError, TxEnv = TxEnvFor<N::Evm>>, Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError, TxEnv = TxEnvFor<N::Evm>>,
{ {
@ -24,7 +33,7 @@ where
impl<N, Rpc> Call for HlEthApi<N, Rpc> impl<N, Rpc> Call for HlEthApi<N, Rpc>
where where
N: RpcNodeCore, N: HlRpcNodeCore,
EthApiError: FromEvmError<N::Evm>, EthApiError: FromEvmError<N::Evm>,
Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError, TxEnv = TxEnvFor<N::Evm>>, Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError, TxEnv = TxEnvFor<N::Evm>>,
{ {
@ -37,4 +46,35 @@ where
fn max_simulate_blocks(&self) -> u64 { fn max_simulate_blocks(&self) -> u64 {
self.inner.eth_api.max_simulate_blocks() self.inner.eth_api.max_simulate_blocks()
} }
fn replay_transactions_until<'a, DB, I>(
&self,
db: &mut DB,
evm_env: EvmEnvFor<Self::Evm>,
transactions: I,
target_tx_hash: B256,
) -> Result<usize, Self::Error>
where
DB: Database<Error = ProviderError> + DatabaseCommit + core::fmt::Debug,
I: IntoIterator<Item = Recovered<&'a ProviderTx<Self::Provider>>>,
{
let block_number = evm_env.block_env().number;
let hl_extras = self.get_hl_extras(block_number.try_into().unwrap())?;
let mut evm = self.evm_config().evm_with_env(db, evm_env);
apply_precompiles(&mut evm, &hl_extras);
let mut index = 0;
for tx in transactions {
if *tx.tx_hash() == target_tx_hash {
// reached the target transaction
break;
}
let tx_env = self.evm_config().tx_env(tx);
evm.transact_commit(tx_env).map_err(Self::Error::from_evm_err)?;
index += 1;
}
Ok(index)
}
} }

View File

@ -1,3 +1,9 @@
use crate::{
chainspec::HlChainSpec,
node::{evm::apply_precompiles, types::HlExtras},
HlBlock, HlPrimitives,
};
use alloy_evm::Evm;
use alloy_network::Ethereum; use alloy_network::Ethereum;
use alloy_primitives::U256; use alloy_primitives::U256;
use reth::{ use reth::{
@ -18,8 +24,9 @@ use reth::{
TaskSpawner, TaskSpawner,
}, },
}; };
use reth_evm::ConfigureEvm; use reth_evm::{ConfigureEvm, Database, EvmEnvFor, HaltReasonFor, InspectorFor, TxEnvFor};
use reth_provider::{ChainSpecProvider, ProviderHeader, ProviderTx}; use reth_primitives::NodePrimitives;
use reth_provider::{BlockReader, ChainSpecProvider, ProviderError, ProviderHeader, ProviderTx};
use reth_rpc::RpcTypes; use reth_rpc::RpcTypes;
use reth_rpc_eth_api::{ use reth_rpc_eth_api::{
helpers::{ helpers::{
@ -29,17 +36,18 @@ use reth_rpc_eth_api::{
EthApiTypes, FromEvmError, RpcConvert, RpcConverter, RpcNodeCore, RpcNodeCoreExt, EthApiTypes, FromEvmError, RpcConvert, RpcConverter, RpcNodeCore, RpcNodeCoreExt,
SignableTxRequest, SignableTxRequest,
}; };
use revm::context::result::ResultAndState;
use std::{fmt, marker::PhantomData, sync::Arc}; use std::{fmt, marker::PhantomData, sync::Arc};
use crate::chainspec::HlChainSpec;
mod block; mod block;
mod call; mod call;
pub mod engine_api; pub mod engine_api;
mod transaction; mod transaction;
pub trait HlRpcNodeCore: RpcNodeCore<Primitives: NodePrimitives<Block = HlBlock>> {}
/// Container type `HlEthApi` /// Container type `HlEthApi`
pub(crate) struct HlEthApiInner<N: RpcNodeCore, Rpc: RpcConvert> { pub(crate) struct HlEthApiInner<N: HlRpcNodeCore, Rpc: RpcConvert> {
/// Gateway to node's core components. /// Gateway to node's core components.
pub(crate) eth_api: EthApiInner<N, Rpc>, pub(crate) eth_api: EthApiInner<N, Rpc>,
} }
@ -48,14 +56,14 @@ type HlRpcConvert<N, NetworkT> =
RpcConverter<NetworkT, <N as FullNodeComponents>::Evm, EthReceiptConverter<HlChainSpec>>; RpcConverter<NetworkT, <N as FullNodeComponents>::Evm, EthReceiptConverter<HlChainSpec>>;
#[derive(Clone)] #[derive(Clone)]
pub struct HlEthApi<N: RpcNodeCore, Rpc: RpcConvert> { pub struct HlEthApi<N: HlRpcNodeCore, Rpc: RpcConvert> {
/// Gateway to node's core components. /// Gateway to node's core components.
pub(crate) inner: Arc<HlEthApiInner<N, Rpc>>, pub(crate) inner: Arc<HlEthApiInner<N, Rpc>>,
} }
impl<N, Rpc> fmt::Debug for HlEthApi<N, Rpc> impl<N, Rpc> fmt::Debug for HlEthApi<N, Rpc>
where where
N: RpcNodeCore, N: HlRpcNodeCore,
Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError>, Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError>,
{ {
fn fmt(&self, f: &mut fmt::Formatter<'_>) -> fmt::Result { fn fmt(&self, f: &mut fmt::Formatter<'_>) -> fmt::Result {
@ -65,7 +73,7 @@ where
impl<N, Rpc> EthApiTypes for HlEthApi<N, Rpc> impl<N, Rpc> EthApiTypes for HlEthApi<N, Rpc>
where where
N: RpcNodeCore, N: HlRpcNodeCore,
Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError>, Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError>,
{ {
type Error = EthApiError; type Error = EthApiError;
@ -79,7 +87,7 @@ where
impl<N, Rpc> RpcNodeCore for HlEthApi<N, Rpc> impl<N, Rpc> RpcNodeCore for HlEthApi<N, Rpc>
where where
N: RpcNodeCore, N: HlRpcNodeCore,
Rpc: RpcConvert<Primitives = N::Primitives>, Rpc: RpcConvert<Primitives = N::Primitives>,
{ {
type Primitives = N::Primitives; type Primitives = N::Primitives;
@ -111,7 +119,7 @@ where
impl<N, Rpc> RpcNodeCoreExt for HlEthApi<N, Rpc> impl<N, Rpc> RpcNodeCoreExt for HlEthApi<N, Rpc>
where where
N: RpcNodeCore, N: HlRpcNodeCore,
Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError>, Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError>,
{ {
#[inline] #[inline]
@ -122,7 +130,7 @@ where
impl<N, Rpc> EthApiSpec for HlEthApi<N, Rpc> impl<N, Rpc> EthApiSpec for HlEthApi<N, Rpc>
where where
N: RpcNodeCore, N: HlRpcNodeCore,
Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError>, Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError>,
{ {
type Transaction = ProviderTx<Self::Provider>; type Transaction = ProviderTx<Self::Provider>;
@ -141,7 +149,7 @@ where
impl<N, Rpc> SpawnBlocking for HlEthApi<N, Rpc> impl<N, Rpc> SpawnBlocking for HlEthApi<N, Rpc>
where where
N: RpcNodeCore, N: HlRpcNodeCore,
Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError>, Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError>,
{ {
#[inline] #[inline]
@ -162,7 +170,7 @@ where
impl<N, Rpc> LoadFee for HlEthApi<N, Rpc> impl<N, Rpc> LoadFee for HlEthApi<N, Rpc>
where where
N: RpcNodeCore, N: HlRpcNodeCore,
EthApiError: FromEvmError<N::Evm>, EthApiError: FromEvmError<N::Evm>,
Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError>, Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError>,
{ {
@ -179,14 +187,14 @@ where
impl<N, Rpc> LoadState for HlEthApi<N, Rpc> impl<N, Rpc> LoadState for HlEthApi<N, Rpc>
where where
N: RpcNodeCore, N: HlRpcNodeCore,
Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError>, Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError>,
{ {
} }
impl<N, Rpc> EthState for HlEthApi<N, Rpc> impl<N, Rpc> EthState for HlEthApi<N, Rpc>
where where
N: RpcNodeCore, N: HlRpcNodeCore,
Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError>, Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError>,
{ {
#[inline] #[inline]
@ -197,7 +205,7 @@ where
impl<N, Rpc> EthFees for HlEthApi<N, Rpc> impl<N, Rpc> EthFees for HlEthApi<N, Rpc>
where where
N: RpcNodeCore, N: HlRpcNodeCore,
EthApiError: FromEvmError<N::Evm>, EthApiError: FromEvmError<N::Evm>,
Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError>, Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError>,
{ {
@ -205,15 +213,50 @@ where
impl<N, Rpc> Trace for HlEthApi<N, Rpc> impl<N, Rpc> Trace for HlEthApi<N, Rpc>
where where
N: RpcNodeCore, N: HlRpcNodeCore,
EthApiError: FromEvmError<N::Evm>, EthApiError: FromEvmError<N::Evm>,
Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError>, Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError>,
{ {
fn inspect<DB, I>(
&self,
db: DB,
evm_env: EvmEnvFor<Self::Evm>,
tx_env: TxEnvFor<Self::Evm>,
inspector: I,
) -> Result<ResultAndState<HaltReasonFor<Self::Evm>>, Self::Error>
where
DB: Database<Error = ProviderError>,
I: InspectorFor<Self::Evm, DB>,
{
let block_number = evm_env.block_env().number;
let hl_extras = self.get_hl_extras(block_number.try_into().unwrap())?;
let mut evm = self.evm_config().evm_with_env_and_inspector(db, evm_env, inspector);
apply_precompiles(&mut evm, &hl_extras);
evm.transact(tx_env).map_err(Self::Error::from_evm_err)
}
}
impl<N, Rpc> HlEthApi<N, Rpc>
where
N: HlRpcNodeCore,
Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError>,
{
fn get_hl_extras(&self, block_number: u64) -> Result<HlExtras, ProviderError> {
Ok(self
.provider()
.block_by_number(block_number)?
.map(|block| HlExtras {
read_precompile_calls: block.body.read_precompile_calls.clone(),
highest_precompile_address: block.body.highest_precompile_address,
})
.unwrap_or_default())
}
} }
impl<N, Rpc> AddDevSigners for HlEthApi<N, Rpc> impl<N, Rpc> AddDevSigners for HlEthApi<N, Rpc>
where where
N: RpcNodeCore, N: HlRpcNodeCore,
Rpc: RpcConvert< Rpc: RpcConvert<
Network: RpcTypes<TransactionRequest: SignableTxRequest<ProviderTx<N::Provider>>>, Network: RpcTypes<TransactionRequest: SignableTxRequest<ProviderTx<N::Provider>>>,
>, >,
@ -239,7 +282,7 @@ impl<NetworkT> Default for HlEthApiBuilder<NetworkT> {
impl<N, NetworkT> EthApiBuilder<N> for HlEthApiBuilder<NetworkT> impl<N, NetworkT> EthApiBuilder<N> for HlEthApiBuilder<NetworkT>
where where
N: FullNodeComponents<Types: NodeTypes<ChainSpec = HlChainSpec>> N: FullNodeComponents<Types: NodeTypes<ChainSpec = HlChainSpec, Primitives = HlPrimitives>>
+ RpcNodeCore< + RpcNodeCore<
Primitives = PrimitivesTy<N::Types>, Primitives = PrimitivesTy<N::Types>,
Evm: ConfigureEvm<NextBlockEnvCtx: BuildPendingEnv<HeaderTy<N::Types>>>, Evm: ConfigureEvm<NextBlockEnvCtx: BuildPendingEnv<HeaderTy<N::Types>>>,

View File

@ -1,21 +1,21 @@
use crate::node::rpc::HlEthApi; use crate::node::rpc::{HlEthApi, HlRpcNodeCore};
use alloy_primitives::{Bytes, B256}; use alloy_primitives::{Bytes, B256};
use reth::rpc::server_types::eth::EthApiError; use reth::rpc::server_types::eth::EthApiError;
use reth_rpc_eth_api::{ use reth_rpc_eth_api::{
helpers::{spec::SignersForRpc, EthTransactions, LoadTransaction}, helpers::{spec::SignersForRpc, EthTransactions, LoadTransaction},
RpcConvert, RpcNodeCore, RpcConvert,
}; };
impl<N, Rpc> LoadTransaction for HlEthApi<N, Rpc> impl<N, Rpc> LoadTransaction for HlEthApi<N, Rpc>
where where
N: RpcNodeCore, N: HlRpcNodeCore,
Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError>, Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError>,
{ {
} }
impl<N, Rpc> EthTransactions for HlEthApi<N, Rpc> impl<N, Rpc> EthTransactions for HlEthApi<N, Rpc>
where where
N: RpcNodeCore, N: HlRpcNodeCore,
Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError>, Rpc: RpcConvert<Primitives = N::Primitives, Error = EthApiError>,
{ {
fn signers(&self) -> &SignersForRpc<Self::Provider, Self::NetworkTypes> { fn signers(&self) -> &SignersForRpc<Self::Provider, Self::NetworkTypes> {

View File

@ -12,7 +12,7 @@ pub mod utils;
use std::sync::Arc; use std::sync::Arc;
use tokio::sync::mpsc; use tokio::sync::mpsc;
use tracing::info; use tracing::{error, info};
pub use cli::*; pub use cli::*;
pub use config::*; pub use config::*;
@ -78,9 +78,12 @@ pub async fn start_pseudo_peer(
_ = transaction_rx.recv() => {} _ = transaction_rx.recv() => {}
Some(eth_req) = eth_rx.recv() => { Some(eth_req) = eth_rx.recv() => {
service.process_eth_request(eth_req).await?; if let Err(e) = service.process_eth_request(eth_req).await {
error!("Error processing eth request: {e:?}");
} else {
info!("Processed eth request"); info!("Processed eth request");
} }
} }
} }
}
} }

View File

@ -152,13 +152,14 @@ impl<BS: BlockSource> PseudoPeer<BS> {
async fn collect_blocks( async fn collect_blocks(
&self, &self,
block_numbers: impl IntoIterator<Item = u64>, block_numbers: impl IntoIterator<Item = u64>,
) -> Vec<BlockAndReceipts> { ) -> eyre::Result<Vec<BlockAndReceipts>> {
let block_numbers = block_numbers.into_iter().collect::<Vec<_>>(); let block_numbers = block_numbers.into_iter().collect::<Vec<_>>();
futures::stream::iter(block_numbers) let res = futures::stream::iter(block_numbers)
.map(async |number| self.collect_block(number).await.unwrap()) .map(async |number| self.collect_block(number).await)
.buffered(self.block_source.recommended_chunk_size() as usize) .buffered(self.block_source.recommended_chunk_size() as usize)
.collect::<Vec<_>>() .collect::<Vec<_>>()
.await .await;
res.into_iter().collect()
} }
pub async fn process_eth_request( pub async fn process_eth_request(
@ -185,7 +186,7 @@ impl<BS: BlockSource> PseudoPeer<BS> {
HeadersDirection::Falling => { HeadersDirection::Falling => {
self.collect_blocks((number + 1 - limit..number + 1).rev()).await self.collect_blocks((number + 1 - limit..number + 1).rev()).await
} }
} }?
.into_par_iter() .into_par_iter()
.map(|block| block.to_reth_block(chain_id).header.clone()) .map(|block| block.to_reth_block(chain_id).header.clone())
.collect::<Vec<_>>(); .collect::<Vec<_>>();
@ -203,7 +204,7 @@ impl<BS: BlockSource> PseudoPeer<BS> {
let block_bodies = self let block_bodies = self
.collect_blocks(numbers) .collect_blocks(numbers)
.await .await?
.into_iter() .into_iter()
.map(|block| block.to_reth_block(chain_id).body) .map(|block| block.to_reth_block(chain_id).body)
.collect::<Vec<_>>(); .collect::<Vec<_>>();
@ -340,7 +341,7 @@ impl<BS: BlockSource> PseudoPeer<BS> {
debug!("Backfilling from {start_number} to {end_number}"); debug!("Backfilling from {start_number} to {end_number}");
// Collect blocks and cache them // Collect blocks and cache them
let blocks = self.collect_blocks(uncached_block_numbers).await; let blocks = self.collect_blocks(uncached_block_numbers).await?;
let block_map: HashMap<B256, u64> = let block_map: HashMap<B256, u64> =
blocks.into_iter().map(|block| (block.hash(), block.number())).collect(); blocks.into_iter().map(|block| (block.hash(), block.number())).collect();
let maybe_block_number = block_map.get(&target_hash).copied(); let maybe_block_number = block_map.get(&target_hash).copied();

View File

@ -17,12 +17,12 @@ impl FileOperations {
files.extend( files.extend(
subentries subentries
.filter_map(|f| f.ok().map(|f| f.path())) .filter_map(|f| f.ok().map(|f| f.path()))
.filter(|p| TimeUtils::datetime_from_path(p).is_some()), .filter_map(|p| TimeUtils::datetime_from_path(&p).map(|dt| (dt, p))),
); );
} }
} }
files.sort(); files.sort();
Some(files) Some(files.into_iter().map(|(_, p)| p).collect())
} }
pub fn find_latest_hourly_file(root: &Path) -> Option<PathBuf> { pub fn find_latest_hourly_file(root: &Path) -> Option<PathBuf> {

View File

@ -193,3 +193,22 @@ async fn test_update_last_fetch_fallback() -> eyre::Result<()> {
Ok(()) Ok(())
} }
#[test]
fn test_hourly_files_sort() -> eyre::Result<()> {
let temp_dir = tempfile::tempdir()?;
// create 20250826/9, 20250826/14
let targets = [("20250826", "9"), ("20250826", "14")];
for (date, hour) in targets {
let hourly_file = temp_dir.path().join(HOURLY_SUBDIR).join(date).join(hour);
let parent = hourly_file.parent().unwrap();
std::fs::create_dir_all(parent)?;
std::fs::File::create(hourly_file)?;
}
let files = FileOperations::all_hourly_files(temp_dir.path()).unwrap();
let file_names: Vec<_> =
files.into_iter().map(|p| p.file_name().unwrap().to_string_lossy().into_owned()).collect();
assert_eq!(file_names, ["9", "14"]);
Ok(())
}