2022-08-24 02:56:47 +03:00
///! Keep track of the blockchain as seen by a Web3Connections.
2022-08-24 03:11:49 +03:00
use super ::connection ::Web3Connection ;
use super ::connections ::Web3Connections ;
2022-08-24 03:59:05 +03:00
use super ::transactions ::TxStatus ;
2022-11-08 22:58:11 +03:00
use crate ::frontend ::authorization ::Authorization ;
2022-08-27 02:44:25 +03:00
use crate ::{
config ::BlockAndRpc , jsonrpc ::JsonRpcRequest , rpcs ::synced_connections ::SyncedConnections ,
} ;
2022-09-01 08:58:55 +03:00
use anyhow ::Context ;
2022-08-26 20:26:17 +03:00
use derive_more ::From ;
2022-08-27 06:11:58 +03:00
use ethers ::prelude ::{ Block , TxHash , H256 , U64 } ;
2022-08-27 02:44:25 +03:00
use hashbrown ::{ HashMap , HashSet } ;
2022-11-12 11:24:32 +03:00
use log ::{ debug , warn , Level } ;
2022-09-05 08:53:58 +03:00
use moka ::future ::Cache ;
2022-09-01 08:58:55 +03:00
use serde ::Serialize ;
2022-08-24 02:56:47 +03:00
use serde_json ::json ;
2022-12-01 01:11:14 +03:00
use std ::time ::{ SystemTime , UNIX_EPOCH } ;
2022-09-01 08:58:55 +03:00
use std ::{ cmp ::Ordering , fmt ::Display , sync ::Arc } ;
2022-08-24 02:56:47 +03:00
use tokio ::sync ::{ broadcast , watch } ;
2022-09-20 09:00:27 +03:00
use tokio ::time ::Duration ;
2022-08-24 02:56:47 +03:00
2022-09-05 08:53:58 +03:00
// TODO: type for Hydrated Blocks with their full transactions?
2022-08-30 23:01:42 +03:00
pub type ArcBlock = Arc < Block < TxHash > > ;
2022-09-20 04:33:39 +03:00
pub type BlockHashesCache = Cache < H256 , ArcBlock , hashbrown ::hash_map ::DefaultHashBuilder > ;
2022-08-30 23:01:42 +03:00
2022-08-27 06:11:58 +03:00
/// A block's hash and number.
2022-09-01 08:58:55 +03:00
#[ derive(Clone, Debug, Default, From, Serialize) ]
2022-12-03 08:31:03 +03:00
pub struct SavedBlock {
pub block : ArcBlock ,
/// number of seconds this block was behind the current time when received
lag : u64 ,
2022-08-26 20:26:17 +03:00
}
2022-12-03 08:31:03 +03:00
impl SavedBlock {
pub fn new ( block : ArcBlock ) -> Self {
// TODO: read this from a global config. different chains should probably have different gaps.
let allowed_lag : u64 = 60 ;
let now = SystemTime ::now ( )
. duration_since ( UNIX_EPOCH )
. expect ( " there should always be time " ) ;
// TODO: get this from config
// TODO: is this safe enough? what if something about the chain is actually lagged? what if its a chain like BTC with 10 minute blocks?
let oldest_allowed = now - Duration ::from_secs ( allowed_lag ) ;
let block_timestamp = Duration ::from_secs ( block . timestamp . as_u64 ( ) ) ;
// TODO: recalculate this every time?
let lag = if block_timestamp < oldest_allowed {
// this server is still syncing from too far away to serve requests
// u64 is safe because ew checked equality above
( oldest_allowed - block_timestamp ) . as_secs ( ) as u64
} else {
0
} ;
Self { block , lag }
}
pub fn hash ( & self ) -> H256 {
self . block . hash . unwrap ( )
}
// TODO: return as U64 or u64?
pub fn number ( & self ) -> U64 {
self . block . number . unwrap ( )
}
/// When the block was received, this node was still syncing
2022-12-03 08:35:29 +03:00
pub fn syncing ( & self ) -> bool {
2022-12-03 08:31:03 +03:00
// TODO: margin should come from a global config
self . lag > 60
}
}
impl From < ArcBlock > for SavedBlock {
fn from ( x : ArcBlock ) -> Self {
SavedBlock ::new ( x )
}
}
impl Display for SavedBlock {
2022-09-01 08:58:55 +03:00
fn fmt ( & self , f : & mut std ::fmt ::Formatter < '_ > ) -> std ::fmt ::Result {
2022-12-03 08:31:03 +03:00
write! ( f , " {} ({}) " , self . number ( ) , self . hash ( ) ) ? ;
2022-12-03 08:35:29 +03:00
if self . syncing ( ) {
2022-12-03 08:31:03 +03:00
write! ( f , " (behind by {} seconds) " , self . lag ) ? ;
}
Ok ( ( ) )
2022-09-01 08:58:55 +03:00
}
}
2022-08-24 02:56:47 +03:00
impl Web3Connections {
2022-12-03 08:31:03 +03:00
/// add a block to our mappings and track the heaviest chain
2022-09-05 09:13:36 +03:00
pub async fn save_block ( & self , block : & ArcBlock , heaviest_chain : bool ) -> anyhow ::Result < ( ) > {
2022-09-03 00:35:03 +03:00
// TODO: i think we can rearrange this function to make it faster on the hot path
2022-09-01 08:58:55 +03:00
let block_hash = block . hash . as_ref ( ) . context ( " no block hash " ) ? ;
2022-09-06 15:29:37 +03:00
2022-09-14 08:26:46 +03:00
// skip Block::default()
2022-09-06 15:29:37 +03:00
if block_hash . is_zero ( ) {
2022-09-14 08:26:46 +03:00
debug! ( " Skipping block without hash! " ) ;
2022-09-06 15:29:37 +03:00
return Ok ( ( ) ) ;
}
2022-10-27 00:39:26 +03:00
let block_num = block . number . as_ref ( ) . context ( " no block num " ) ? ;
2022-09-30 07:18:18 +03:00
// TODO: think more about heaviest_chain. would be better to do the check inside this function
2022-09-05 09:13:36 +03:00
if heaviest_chain {
// this is the only place that writes to block_numbers
2022-09-14 08:26:46 +03:00
// multiple inserts should be okay though
2022-12-03 08:31:03 +03:00
// TODO: info that there was a fork?
2022-09-05 08:53:58 +03:00
self . block_numbers . insert ( * block_num , * block_hash ) . await ;
2022-09-02 08:40:56 +03:00
}
2022-12-03 08:31:03 +03:00
// this block is very likely already in block_hashes
// TODO: use their get_with
2022-09-05 09:13:36 +03:00
self . block_hashes
2022-12-03 08:31:03 +03:00
. get_with ( * block_hash , async move { block . clone ( ) } )
2022-09-05 09:13:36 +03:00
. await ;
2022-08-26 20:26:17 +03:00
Ok ( ( ) )
2022-08-24 02:56:47 +03:00
}
2022-08-27 05:13:36 +03:00
/// Get a block from caches with fallback.
/// Will query a specific node or the best available.
2022-08-26 20:26:17 +03:00
pub async fn block (
& self ,
2022-11-08 22:58:11 +03:00
authorization : & Arc < Authorization > ,
2022-08-26 20:26:17 +03:00
hash : & H256 ,
2022-08-27 05:13:36 +03:00
rpc : Option < & Arc < Web3Connection > > ,
2022-08-30 23:01:42 +03:00
) -> anyhow ::Result < ArcBlock > {
2022-08-24 02:56:47 +03:00
// first, try to get the hash from our cache
2022-09-03 00:35:03 +03:00
// the cache is set last, so if its here, its everywhere
2022-08-28 02:49:41 +03:00
if let Some ( block ) = self . block_hashes . get ( hash ) {
2022-09-05 08:53:58 +03:00
return Ok ( block ) ;
2022-08-24 02:56:47 +03:00
}
// block not in cache. we need to ask an rpc for it
2022-09-23 00:51:52 +03:00
let get_block_params = ( * hash , false ) ;
2022-08-24 02:56:47 +03:00
// TODO: if error, retry?
2022-11-21 01:52:08 +03:00
let block : ArcBlock = match rpc {
2022-08-26 20:26:17 +03:00
Some ( rpc ) = > {
2022-11-08 22:58:11 +03:00
rpc . wait_for_request_handle ( authorization , Duration ::from_secs ( 30 ) )
2022-08-27 05:13:36 +03:00
. await ?
2022-09-24 05:47:44 +03:00
. request (
" eth_getBlockByHash " ,
& json! ( get_block_params ) ,
2022-11-12 11:24:32 +03:00
Level ::Error . into ( ) ,
2022-09-24 05:47:44 +03:00
)
2022-08-27 05:13:36 +03:00
. await ?
2022-08-26 20:26:17 +03:00
}
2022-08-27 05:13:36 +03:00
None = > {
2022-09-02 08:40:56 +03:00
// TODO: helper for method+params => JsonRpcRequest
// TODO: does this id matter?
2022-09-03 00:35:03 +03:00
let request = json! ( { " id " : " 1 " , " method " : " eth_getBlockByHash " , " params " : get_block_params } ) ;
2022-08-27 05:13:36 +03:00
let request : JsonRpcRequest = serde_json ::from_value ( request ) ? ;
2022-08-24 02:56:47 +03:00
2022-11-08 22:58:11 +03:00
// TODO: request_metadata? maybe we should put it in the authorization?
2022-09-22 23:27:14 +03:00
let response = self
2022-11-08 22:58:11 +03:00
. try_send_best_upstream_server ( authorization , request , None , None )
2022-09-22 23:27:14 +03:00
. await ? ;
2022-08-24 02:56:47 +03:00
2022-12-01 05:01:41 +03:00
let block = response . result . context ( " failed fetching block " ) ? ;
2022-08-27 05:13:36 +03:00
serde_json ::from_str ( block . get ( ) ) ?
}
} ;
2022-08-24 02:56:47 +03:00
2022-08-30 23:01:42 +03:00
// the block was fetched using eth_getBlockByHash, so it should have all fields
2022-09-14 08:26:46 +03:00
// TODO: fill in heaviest_chain! if the block is old enough, is this definitely true?
2022-09-14 07:27:18 +03:00
self . save_block ( & block , false ) . await ? ;
2022-08-24 02:56:47 +03:00
Ok ( block )
}
/// Convenience method to get the cannonical block at a given block height.
2022-11-08 22:58:11 +03:00
pub async fn block_hash (
& self ,
authorization : & Arc < Authorization > ,
num : & U64 ,
) -> anyhow ::Result < ( H256 , bool ) > {
let ( block , is_archive_block ) = self . cannonical_block ( authorization , num ) . await ? ;
2022-08-24 02:56:47 +03:00
2022-11-03 02:14:16 +03:00
let hash = block . hash . expect ( " Saved blocks should always have hashes " ) ;
2022-08-24 02:56:47 +03:00
2022-11-03 02:14:16 +03:00
Ok ( ( hash , is_archive_block ) )
2022-08-24 02:56:47 +03:00
}
/// Get the heaviest chain's block from cache or backend rpc
2022-11-08 22:58:11 +03:00
pub async fn cannonical_block (
& self ,
authorization : & Arc < Authorization > ,
num : & U64 ,
) -> anyhow ::Result < ( ArcBlock , bool ) > {
2022-08-28 02:49:41 +03:00
// we only have blocks by hash now
2022-09-05 08:53:58 +03:00
// maybe save them during save_block in a blocks_by_number Cache<U64, Vec<ArcBlock>>
2022-08-28 02:49:41 +03:00
// if theres multiple, use petgraph to find the one on the main chain (and remove the others if they have enough confirmations)
2022-08-26 20:26:17 +03:00
2022-09-03 00:35:03 +03:00
// be sure the requested block num exists
2022-09-14 05:11:48 +03:00
let head_block_num = self . head_block_num ( ) . context ( " no servers in sync " ) ? ;
2022-11-03 02:14:16 +03:00
2022-12-03 08:31:03 +03:00
// TODO: geth does 64, erigon does 90k. sometimes we run a mix
2022-11-03 02:14:16 +03:00
let archive_needed = num < & ( head_block_num - U64 ::from ( 64 ) ) ;
2022-08-24 02:56:47 +03:00
if num > & head_block_num {
// TODO: i'm seeing this a lot when using ethspam. i dont know why though. i thought we delayed publishing
// TODO: instead of error, maybe just sleep and try again?
2022-11-03 02:14:16 +03:00
// TODO: this should be a 401, not a 500
2022-08-24 02:56:47 +03:00
return Err ( anyhow ::anyhow! (
" Head block is #{}, but #{} was requested " ,
head_block_num ,
num
) ) ;
}
2022-09-03 00:35:03 +03:00
// try to get the hash from our cache
// deref to not keep the lock open
2022-09-05 08:53:58 +03:00
if let Some ( block_hash ) = self . block_numbers . get ( num ) {
2022-09-03 00:35:03 +03:00
// TODO: sometimes this needs to fetch the block. why? i thought block_numbers would only be set if the block hash was set
2022-11-08 22:58:11 +03:00
// TODO: pass authorization through here?
let block = self . block ( authorization , & block_hash , None ) . await ? ;
2022-11-03 02:14:16 +03:00
return Ok ( ( block , archive_needed ) ) ;
2022-09-03 00:35:03 +03:00
}
// block number not in cache. we need to ask an rpc for it
2022-08-24 02:56:47 +03:00
// TODO: helper for method+params => JsonRpcRequest
let request = json! ( { " jsonrpc " : " 2.0 " , " id " : " 1 " , " method " : " eth_getBlockByNumber " , " params " : ( num , false ) } ) ;
let request : JsonRpcRequest = serde_json ::from_value ( request ) ? ;
// TODO: if error, retry?
2022-11-08 22:58:11 +03:00
// TODO: request_metadata or authorization?
2022-08-24 02:56:47 +03:00
let response = self
2022-11-08 22:58:11 +03:00
. try_send_best_upstream_server ( authorization , request , None , Some ( num ) )
2022-08-24 02:56:47 +03:00
. await ? ;
2022-09-02 23:16:20 +03:00
let raw_block = response . result . context ( " no block result " ) ? ;
2022-08-24 02:56:47 +03:00
2022-11-21 01:52:08 +03:00
let block : ArcBlock = serde_json ::from_str ( raw_block . get ( ) ) ? ;
2022-08-24 02:56:47 +03:00
2022-09-02 08:40:56 +03:00
// the block was fetched using eth_getBlockByNumber, so it should have all fields and be on the heaviest chain
2022-09-05 09:13:36 +03:00
self . save_block ( & block , true ) . await ? ;
2022-08-24 02:56:47 +03:00
2022-12-03 08:31:03 +03:00
Ok ( ( block , archive_needed ) )
2022-08-24 02:56:47 +03:00
}
2022-08-26 20:26:17 +03:00
pub ( super ) async fn process_incoming_blocks (
2022-08-24 03:59:05 +03:00
& self ,
2022-11-08 22:58:11 +03:00
authorization : & Arc < Authorization > ,
2022-08-26 20:26:17 +03:00
block_receiver : flume ::Receiver < BlockAndRpc > ,
2022-09-05 08:53:58 +03:00
// TODO: document that this is a watch sender and not a broadcast! if things get busy, blocks might get missed
// Geth's subscriptions have the same potential for skipping blocks.
2022-08-30 23:01:42 +03:00
head_block_sender : watch ::Sender < ArcBlock > ,
2022-08-24 03:59:05 +03:00
pending_tx_sender : Option < broadcast ::Sender < TxStatus > > ,
) -> anyhow ::Result < ( ) > {
// TODO: indexmap or hashmap? what hasher? with_capacity?
2022-08-26 20:26:17 +03:00
// TODO: this will grow unbounded. prune old heads on this at the same time we prune the graph?
let mut connection_heads = HashMap ::new ( ) ;
2022-08-24 03:59:05 +03:00
while let Ok ( ( new_block , rpc ) ) = block_receiver . recv_async ( ) . await {
2022-12-03 08:31:03 +03:00
let new_block = new_block . map ( Into ::into ) ;
2022-09-14 08:26:46 +03:00
let rpc_name = rpc . name . clone ( ) ;
2022-12-03 08:31:03 +03:00
2022-09-14 08:26:46 +03:00
if let Err ( err ) = self
. process_block_from_rpc (
2022-11-08 22:58:11 +03:00
authorization ,
2022-09-14 08:26:46 +03:00
& mut connection_heads ,
new_block ,
rpc ,
& head_block_sender ,
& pending_tx_sender ,
)
. await
{
2022-11-12 11:24:32 +03:00
warn! ( " unable to process block from rpc {}: {:?} " , rpc_name , err ) ;
2022-09-14 08:26:46 +03:00
}
2022-08-24 03:59:05 +03:00
}
// TODO: if there was an error, we should return it
warn! ( " block_receiver exited! " ) ;
Ok ( ( ) )
}
2022-08-26 20:26:17 +03:00
/// `connection_heads` is a mapping of rpc_names to head block hashes.
2022-11-21 01:52:08 +03:00
/// self.blockchain_map is a mapping of hashes to the complete ArcBlock.
2022-08-27 02:44:25 +03:00
/// TODO: return something?
2022-11-23 01:45:22 +03:00
pub ( crate ) async fn process_block_from_rpc (
2022-08-24 02:56:47 +03:00
& self ,
2022-11-08 22:58:11 +03:00
authorization : & Arc < Authorization > ,
2022-08-26 20:26:17 +03:00
connection_heads : & mut HashMap < String , H256 > ,
2022-12-03 08:31:03 +03:00
rpc_head_block : Option < SavedBlock > ,
2022-08-24 02:56:47 +03:00
rpc : Arc < Web3Connection > ,
2022-08-30 23:01:42 +03:00
head_block_sender : & watch ::Sender < ArcBlock > ,
2022-08-24 03:59:05 +03:00
pending_tx_sender : & Option < broadcast ::Sender < TxStatus > > ,
2022-08-24 02:56:47 +03:00
) -> anyhow ::Result < ( ) > {
2022-09-06 15:29:37 +03:00
// add the rpc's block to connection_heads, or remove the rpc from connection_heads
2022-12-03 08:31:03 +03:00
let rpc_head_block = match rpc_head_block {
2022-09-06 15:29:37 +03:00
Some ( rpc_head_block ) = > {
2022-12-03 08:31:03 +03:00
let rpc_head_num = rpc_head_block . number ( ) ;
let rpc_head_hash = rpc_head_block . hash ( ) ;
2022-09-06 15:29:37 +03:00
2022-11-23 01:45:22 +03:00
// we don't know if its on the heaviest chain yet
2022-12-03 08:31:03 +03:00
self . save_block ( & rpc_head_block . block , false ) . await ? ;
2022-12-01 01:11:14 +03:00
2022-12-03 08:35:29 +03:00
if rpc_head_block . syncing ( ) {
2022-12-01 05:01:41 +03:00
if connection_heads . remove ( & rpc . name ) . is_some ( ) {
2022-12-03 08:31:03 +03:00
warn! ( " {} is behind by {} seconds " , & rpc . name , rpc_head_block . lag ) ;
2022-12-01 05:01:41 +03:00
} ;
2022-12-01 01:11:14 +03:00
None
} else {
2022-12-03 08:31:03 +03:00
if let Some ( prev_hash ) =
connection_heads . insert ( rpc . name . to_owned ( ) , rpc_head_hash )
{
if prev_hash = = rpc_head_hash {
// this block was already sent by this node. return early
return Ok ( ( ) ) ;
}
}
2022-12-01 01:11:14 +03:00
2022-12-03 08:31:03 +03:00
// TODO: should we just keep the ArcBlock here?
Some ( rpc_head_block )
2022-12-01 01:11:14 +03:00
}
2022-08-26 20:26:17 +03:00
}
2022-09-06 15:29:37 +03:00
None = > {
2022-09-02 23:46:39 +03:00
// TODO: warn is too verbose. this is expected if a node disconnects and has to reconnect
2022-11-12 11:24:32 +03:00
// // trace!(%rpc, "Block without number or hash!");
2022-08-24 02:56:47 +03:00
2022-12-03 08:31:03 +03:00
if connection_heads . remove ( & rpc . name ) . is_none ( ) {
// this connection was already removed.
// return early. no need to process synced connections
return Ok ( ( ) ) ;
}
2022-09-06 19:49:07 +03:00
None
2022-08-24 02:56:47 +03:00
}
2022-09-01 08:58:55 +03:00
} ;
2022-08-24 02:56:47 +03:00
2022-09-02 08:40:56 +03:00
// iterate the known heads to find the highest_work_block
2022-08-27 02:44:25 +03:00
let mut checked_heads = HashSet ::new ( ) ;
2022-09-14 22:39:08 +03:00
let mut highest_num_block : Option < ArcBlock > = None ;
2022-09-12 17:33:55 +03:00
for ( conn_name , connection_head_hash ) in connection_heads . iter ( ) {
if checked_heads . contains ( connection_head_hash ) {
2022-09-02 08:40:56 +03:00
// we already checked this head from another rpc
2022-08-27 02:44:25 +03:00
continue ;
}
2022-09-02 08:40:56 +03:00
// don't check the same hash multiple times
2022-09-12 17:33:55 +03:00
checked_heads . insert ( connection_head_hash ) ;
2022-08-26 20:26:17 +03:00
2022-09-12 17:33:55 +03:00
let conn_head_block = if let Some ( x ) = self . block_hashes . get ( connection_head_hash ) {
2022-09-02 23:46:39 +03:00
x
} else {
2022-09-14 22:39:08 +03:00
// TODO: why does this happen?!?! seems to only happen with uncled blocks
2022-09-14 08:26:46 +03:00
// TODO: maybe we should do get_with?
// TODO: maybe we should just continue. this only seems to happen when an older block is received
2022-11-12 11:24:32 +03:00
warn! ( " Missing connection_head_block in block_hashes. Fetching now. hash={}. other={}. rpc={} " , connection_head_hash , conn_name , rpc ) ;
2022-09-14 08:26:46 +03:00
// this option should always be populated
let conn_rpc = self . conns . get ( conn_name ) ;
2022-11-08 22:58:11 +03:00
match self
. block ( authorization , connection_head_hash , conn_rpc )
. await
{
2022-09-14 08:26:46 +03:00
Ok ( block ) = > block ,
Err ( err ) = > {
2022-11-12 11:24:32 +03:00
warn! ( " Processing {}. Failed fetching connection_head_block for block_hashes. {} head hash={}. err={:?} " , rpc , conn_name , connection_head_hash , err ) ;
2022-09-14 08:26:46 +03:00
continue ;
}
}
2022-09-02 23:46:39 +03:00
} ;
2022-08-24 02:56:47 +03:00
2022-09-14 22:39:08 +03:00
match & conn_head_block . number {
2022-08-30 23:01:42 +03:00
None = > {
2022-09-14 22:39:08 +03:00
panic! ( " block is missing number. this is a bug " ) ;
2022-08-30 23:01:42 +03:00
}
2022-09-14 22:39:08 +03:00
Some ( conn_head_num ) = > {
2022-09-02 08:40:56 +03:00
// if this is the first block we've tried
2022-09-14 22:39:08 +03:00
// or if this rpc's newest block has a higher number
// we used to check total difficulty, but that isn't a thing anymore
if highest_num_block . is_none ( )
| | conn_head_num
> highest_num_block
2022-08-30 23:01:42 +03:00
. as_ref ( )
. expect ( " there should always be a block here " )
2022-09-14 22:39:08 +03:00
. number
2022-08-30 23:01:42 +03:00
. as_ref ( )
2022-09-14 22:39:08 +03:00
. expect ( " there should always be number here " )
2022-08-30 23:01:42 +03:00
{
2022-09-14 22:39:08 +03:00
highest_num_block = Some ( conn_head_block ) ;
2022-08-30 23:01:42 +03:00
}
}
2022-08-27 02:44:25 +03:00
}
}
2022-08-24 02:56:47 +03:00
2022-09-14 22:39:08 +03:00
if let Some ( mut maybe_head_block ) = highest_num_block {
2022-09-02 08:40:56 +03:00
// track rpcs on this heaviest chain so we can build a new SyncedConnections
2022-09-14 22:39:08 +03:00
let mut highest_rpcs = HashSet ::< & String > ::new ( ) ;
// a running total of the soft limits covered by the rpcs that agree on the head block
let mut highest_rpcs_sum_soft_limit : u32 = 0 ;
// TODO: also track highest_rpcs_sum_hard_limit? llama doesn't need this, so it can wait
2022-09-02 08:40:56 +03:00
// check the highest work block for a set of rpcs that can serve our request load
// if it doesn't have enough rpcs for our request load, check the parent block
// TODO: loop for how many parent blocks? we don't want to serve blocks that are too far behind. probably different per chain
// TODO: this loop is pretty long. any way to clean up this code?
for _ in 0 .. 3 {
let maybe_head_hash = maybe_head_block
. hash
. as_ref ( )
. expect ( " blocks here always need hashes " ) ;
// find all rpcs with maybe_head_block as their current head
for ( conn_name , conn_head_hash ) in connection_heads . iter ( ) {
if conn_head_hash ! = maybe_head_hash {
2022-09-05 19:29:21 +03:00
// connection is not on the desired block
continue ;
}
2022-09-14 22:39:08 +03:00
if highest_rpcs . contains ( conn_name ) {
2022-09-05 19:29:21 +03:00
// connection is on a child block
2022-09-02 08:40:56 +03:00
continue ;
}
2022-08-27 02:44:25 +03:00
2022-09-02 08:40:56 +03:00
if let Some ( rpc ) = self . conns . get ( conn_name ) {
2022-09-14 22:39:08 +03:00
highest_rpcs . insert ( conn_name ) ;
highest_rpcs_sum_soft_limit + = rpc . soft_limit ;
2022-09-02 08:40:56 +03:00
} else {
warn! ( " connection missing " )
2022-08-27 02:44:25 +03:00
}
}
2022-09-14 22:39:08 +03:00
if highest_rpcs_sum_soft_limit < self . min_sum_soft_limit
2022-11-23 01:45:22 +03:00
| | highest_rpcs . len ( ) < self . min_head_rpcs
2022-09-02 08:40:56 +03:00
{
// not enough rpcs yet. check the parent
if let Some ( parent_block ) = self . block_hashes . get ( & maybe_head_block . parent_hash )
{
2022-11-12 11:24:32 +03:00
// // trace!(
// child=%maybe_head_hash, parent=%parent_block.hash.unwrap(), "avoiding thundering herd",
// );
2022-09-02 08:40:56 +03:00
2022-09-14 22:39:08 +03:00
maybe_head_block = parent_block ;
2022-09-02 08:40:56 +03:00
continue ;
} else {
warn! (
" no parent to check. soft limit only {}/{} from {}/{} rpcs: {}% " ,
2022-09-14 22:39:08 +03:00
highest_rpcs_sum_soft_limit ,
2022-09-02 08:40:56 +03:00
self . min_sum_soft_limit ,
2022-09-14 22:39:08 +03:00
highest_rpcs . len ( ) ,
2022-11-23 01:45:22 +03:00
self . min_head_rpcs ,
2022-09-14 22:39:08 +03:00
highest_rpcs_sum_soft_limit * 100 / self . min_sum_soft_limit
2022-09-02 08:40:56 +03:00
) ;
break ;
2022-08-27 02:44:25 +03:00
}
2022-08-24 02:56:47 +03:00
}
2022-09-05 19:25:21 +03:00
}
2022-09-14 22:39:08 +03:00
// TODO: if consensus_head_rpcs.is_empty, try another method of finding the head block
2022-09-05 19:25:21 +03:00
2022-09-06 15:29:37 +03:00
let num_connection_heads = connection_heads . len ( ) ;
let total_conns = self . conns . len ( ) ;
2022-09-05 19:25:21 +03:00
// we've done all the searching for the heaviest block that we can
2022-09-14 22:39:08 +03:00
if highest_rpcs . is_empty ( ) {
2022-09-05 19:25:21 +03:00
// if we get here, something is wrong. clear synced connections
let empty_synced_connections = SyncedConnections ::default ( ) ;
2022-11-01 21:54:39 +03:00
let _ = self
2022-09-05 19:25:21 +03:00
. synced_connections
. swap ( Arc ::new ( empty_synced_connections ) ) ;
2022-08-24 02:56:47 +03:00
2022-09-05 19:25:21 +03:00
// TODO: log different things depending on old_synced_connections
2022-11-12 11:24:32 +03:00
warn! (
" Processing {}. no consensus head! {}/{}/{} " ,
rpc , 0 , num_connection_heads , total_conns
) ;
2022-09-05 19:25:21 +03:00
} else {
2022-11-12 11:24:32 +03:00
// // trace!(?highest_rpcs);
2022-09-06 15:29:37 +03:00
2022-09-14 07:27:18 +03:00
// TODO: if maybe_head_block.time() is old, ignore it
2022-09-02 08:40:56 +03:00
// success! this block has enough soft limit and nodes on it (or on later blocks)
2022-09-14 22:39:08 +03:00
let conns : Vec < Arc < Web3Connection > > = highest_rpcs
2022-09-05 19:25:21 +03:00
. into_iter ( )
. filter_map ( | conn_name | self . conns . get ( conn_name ) . cloned ( ) )
. collect ( ) ;
2022-09-02 08:40:56 +03:00
2022-12-03 08:31:03 +03:00
let consensus_head_hash = maybe_head_block
2022-09-14 22:39:08 +03:00
. hash
. expect ( " head blocks always have hashes " ) ;
2022-12-03 08:31:03 +03:00
let consensus_head_num = maybe_head_block
2022-09-14 22:39:08 +03:00
. number
. expect ( " head blocks always have numbers " ) ;
2022-09-02 08:40:56 +03:00
2022-09-05 19:25:21 +03:00
let num_consensus_rpcs = conns . len ( ) ;
2022-12-03 08:31:03 +03:00
let consensus_head_block : SavedBlock = maybe_head_block . into ( ) ;
2022-09-02 08:40:56 +03:00
let new_synced_connections = SyncedConnections {
2022-12-03 08:31:03 +03:00
head_block_id : Some ( consensus_head_block . clone ( ) ) ,
2022-09-02 08:40:56 +03:00
conns ,
} ;
let old_synced_connections = self
. synced_connections
. swap ( Arc ::new ( new_synced_connections ) ) ;
2022-09-14 22:39:08 +03:00
// TODO: if the rpc_head_block != consensus_head_block, log something?
2022-09-02 08:40:56 +03:00
match & old_synced_connections . head_block_id {
None = > {
2022-11-12 11:24:32 +03:00
debug! (
" first {}/{}/{} block={}, rpc={} " ,
num_consensus_rpcs ,
num_connection_heads ,
total_conns ,
2022-12-03 08:31:03 +03:00
consensus_head_block ,
2022-11-12 11:24:32 +03:00
rpc
) ;
2022-09-02 23:16:20 +03:00
2022-12-03 08:31:03 +03:00
self . save_block ( & consensus_head_block . block , true ) . await ? ;
2022-09-02 23:16:20 +03:00
2022-10-21 02:50:23 +03:00
head_block_sender
2022-12-03 08:31:03 +03:00
. send ( consensus_head_block . block )
2022-10-21 02:50:23 +03:00
. context ( " head_block_sender sending consensus_head_block " ) ? ;
2022-09-02 08:40:56 +03:00
}
2022-12-03 08:31:03 +03:00
Some ( old_head_block ) = > {
2022-09-06 19:49:07 +03:00
// TODO: do this log item better
2022-12-03 08:31:03 +03:00
let rpc_head_str = rpc_head_block
2022-09-06 19:49:07 +03:00
. map ( | x | x . to_string ( ) )
. unwrap_or_else ( | | " None " . to_string ( ) ) ;
2022-12-03 08:31:03 +03:00
match consensus_head_block . number ( ) . cmp ( & old_head_block . number ( ) ) {
2022-09-02 08:40:56 +03:00
Ordering ::Equal = > {
2022-09-14 22:39:08 +03:00
// TODO: if rpc_block_id != consensus_head_block_id, do a different log?
2022-09-06 19:49:07 +03:00
2022-09-02 08:40:56 +03:00
// multiple blocks with the same fork!
2022-12-03 08:31:03 +03:00
if consensus_head_block . hash ( ) = = old_head_block . hash ( ) {
2022-09-02 08:40:56 +03:00
// no change in hash. no need to use head_block_sender
2022-11-12 11:24:32 +03:00
debug! (
2022-12-03 08:49:41 +03:00
" con {}/{}/{} con_head={} rpc_head={} rpc={} " ,
2022-11-12 11:24:32 +03:00
num_consensus_rpcs ,
num_connection_heads ,
total_conns ,
2022-12-03 08:31:03 +03:00
consensus_head_block ,
2022-12-03 08:55:46 +03:00
rpc_head_str ,
2022-12-03 08:49:41 +03:00
rpc ,
2022-11-12 11:24:32 +03:00
)
2022-09-02 08:40:56 +03:00
} else {
// hash changed
2022-11-12 11:24:32 +03:00
debug! (
2022-11-14 00:05:37 +03:00
" unc {}/{}/{} con_head={} old={} rpc_head={} rpc={} " ,
2022-11-12 11:24:32 +03:00
num_consensus_rpcs ,
num_connection_heads ,
total_conns ,
2022-12-03 08:31:03 +03:00
consensus_head_block ,
old_head_block ,
2022-11-12 11:24:32 +03:00
rpc_head_str ,
2022-12-03 08:55:46 +03:00
rpc ,
2022-11-12 11:24:32 +03:00
) ;
2022-09-02 08:40:56 +03:00
2022-12-03 08:31:03 +03:00
self . save_block ( & consensus_head_block . block , true )
2022-10-21 02:50:23 +03:00
. await
. context ( " save consensus_head_block as heaviest chain " ) ? ;
2022-09-02 08:40:56 +03:00
2022-12-03 08:31:03 +03:00
head_block_sender . send ( consensus_head_block . block ) . context (
2022-10-21 02:50:23 +03:00
" head_block_sender sending consensus_head_block " ,
) ? ;
2022-09-02 08:40:56 +03:00
}
}
Ordering ::Less = > {
// this is unlikely but possible
// TODO: better log
2022-12-03 08:31:03 +03:00
warn! ( " chain rolled back {}/{}/{} con_head={} old_head={} rpc_head={} rpc={} " , num_consensus_rpcs , num_connection_heads , total_conns , consensus_head_block , old_head_block , rpc_head_str , rpc ) ;
2022-09-02 23:16:20 +03:00
2022-09-14 22:39:08 +03:00
// TODO: tell save_block to remove any higher block numbers from the cache. not needed because we have other checks on requested blocks being > head, but still seems slike a good idea
2022-12-03 08:31:03 +03:00
self . save_block ( & consensus_head_block . block , true )
. await
. context (
" save_block sending consensus_head_block as heaviest chain " ,
) ? ;
2022-09-02 23:16:20 +03:00
2022-10-21 02:50:23 +03:00
head_block_sender
2022-12-03 08:31:03 +03:00
. send ( consensus_head_block . block )
2022-10-21 02:50:23 +03:00
. context ( " head_block_sender sending consensus_head_block " ) ? ;
2022-09-02 08:40:56 +03:00
}
Ordering ::Greater = > {
2022-11-12 11:24:32 +03:00
debug! (
2022-12-03 08:35:29 +03:00
" new {}/{}/{} con_head={} rpc_head={} rpc={} " ,
2022-11-12 11:24:32 +03:00
num_consensus_rpcs ,
num_connection_heads ,
total_conns ,
2022-12-03 08:31:03 +03:00
consensus_head_block ,
2022-11-12 11:24:32 +03:00
rpc_head_str ,
rpc
) ;
2022-09-02 08:40:56 +03:00
2022-12-03 08:31:03 +03:00
self . save_block ( & consensus_head_block . block , true ) . await ? ;
2022-09-02 23:16:20 +03:00
2022-12-03 08:31:03 +03:00
head_block_sender . send ( consensus_head_block . block ) ? ;
2022-09-02 08:40:56 +03:00
}
}
}
2022-08-24 02:56:47 +03:00
}
}
2022-08-27 02:44:25 +03:00
}
2022-09-02 23:16:20 +03:00
Ok ( ( ) )
2022-08-24 02:56:47 +03:00
}
}