reth_network/
network.rs

1use crate::{
2    config::NetworkMode, message::PeerMessage, protocol::RlpxSubProtocol,
3    swarm::NetworkConnectionState, transactions::TransactionsHandle, FetchClient,
4};
5use alloy_primitives::B256;
6use enr::Enr;
7use futures::StreamExt;
8use parking_lot::Mutex;
9use reth_discv4::{Discv4, NatResolver};
10use reth_discv5::Discv5;
11use reth_eth_wire::{
12    BlockRangeUpdate, DisconnectReason, EthNetworkPrimitives, NetworkPrimitives,
13    NewPooledTransactionHashes, SharedTransactions,
14};
15use reth_ethereum_forks::Head;
16use reth_network_api::{
17    events::{NetworkPeersEvents, PeerEvent, PeerEventStream},
18    test_utils::{PeersHandle, PeersHandleProvider},
19    BlockDownloaderProvider, DiscoveryEvent, NetworkError, NetworkEvent,
20    NetworkEventListenerProvider, NetworkInfo, NetworkStatus, PeerInfo, PeerRequest, Peers,
21    PeersInfo,
22};
23use reth_network_p2p::sync::{NetworkSyncUpdater, SyncState, SyncStateProvider};
24use reth_network_peers::{NodeRecord, PeerId};
25use reth_network_types::{PeerAddr, PeerKind, Reputation, ReputationChangeKind};
26use reth_tokio_util::{EventSender, EventStream};
27use secp256k1::SecretKey;
28use std::{
29    net::SocketAddr,
30    sync::{
31        atomic::{AtomicBool, AtomicU64, AtomicUsize, Ordering},
32        Arc,
33    },
34};
35use tokio::sync::{
36    mpsc::{self, UnboundedSender},
37    oneshot,
38};
39use tokio_stream::wrappers::UnboundedReceiverStream;
40
41/// A _shareable_ network frontend. Used to interact with the network.
42///
43/// See also [`NetworkManager`](crate::NetworkManager).
44#[derive(Clone, Debug)]
45pub struct NetworkHandle<N: NetworkPrimitives = EthNetworkPrimitives> {
46    /// The Arc'ed delegate that contains the state.
47    inner: Arc<NetworkInner<N>>,
48}
49
50// === impl NetworkHandle ===
51
52impl<N: NetworkPrimitives> NetworkHandle<N> {
53    /// Creates a single new instance.
54    #[expect(clippy::too_many_arguments)]
55    pub(crate) fn new(
56        num_active_peers: Arc<AtomicUsize>,
57        listener_address: Arc<Mutex<SocketAddr>>,
58        to_manager_tx: UnboundedSender<NetworkHandleMessage<N>>,
59        secret_key: SecretKey,
60        local_peer_id: PeerId,
61        peers: PeersHandle,
62        network_mode: NetworkMode,
63        chain_id: Arc<AtomicU64>,
64        tx_gossip_disabled: bool,
65        discv4: Option<Discv4>,
66        discv5: Option<Discv5>,
67        event_sender: EventSender<NetworkEvent<PeerRequest<N>>>,
68        nat: Option<NatResolver>,
69    ) -> Self {
70        let inner = NetworkInner {
71            num_active_peers,
72            to_manager_tx,
73            listener_address,
74            secret_key,
75            local_peer_id,
76            peers,
77            network_mode,
78            is_syncing: Arc::new(AtomicBool::new(false)),
79            initial_sync_done: Arc::new(AtomicBool::new(false)),
80            chain_id,
81            tx_gossip_disabled,
82            discv4,
83            discv5,
84            event_sender,
85            nat,
86        };
87        Self { inner: Arc::new(inner) }
88    }
89
90    /// Returns the [`PeerId`] used in the network.
91    pub fn peer_id(&self) -> &PeerId {
92        &self.inner.local_peer_id
93    }
94
95    fn manager(&self) -> &UnboundedSender<NetworkHandleMessage<N>> {
96        &self.inner.to_manager_tx
97    }
98
99    /// Returns the mode of the network, either pow, or pos
100    pub fn mode(&self) -> &NetworkMode {
101        &self.inner.network_mode
102    }
103
104    /// Sends a [`NetworkHandleMessage`] to the manager
105    pub(crate) fn send_message(&self, msg: NetworkHandleMessage<N>) {
106        let _ = self.inner.to_manager_tx.send(msg);
107    }
108
109    /// Update the status of the node.
110    pub fn update_status(&self, head: Head) {
111        self.send_message(NetworkHandleMessage::StatusUpdate { head });
112    }
113
114    /// Announce a block over devp2p
115    ///
116    /// Caution: in `PoS` this is a noop because new blocks are no longer announced over devp2p.
117    /// Instead they are sent to the node by CL and can be requested over devp2p.
118    /// Broadcasting new blocks is considered a protocol violation.
119    pub fn announce_block(&self, block: N::NewBlockPayload, hash: B256) {
120        self.send_message(NetworkHandleMessage::AnnounceBlock(block, hash))
121    }
122
123    /// Sends a [`PeerRequest`] to the given peer's session.
124    pub fn send_request(&self, peer_id: PeerId, request: PeerRequest<N>) {
125        self.send_message(NetworkHandleMessage::EthRequest { peer_id, request })
126    }
127
128    /// Send transactions hashes to the peer.
129    pub fn send_transactions_hashes(&self, peer_id: PeerId, msg: NewPooledTransactionHashes) {
130        self.send_message(NetworkHandleMessage::SendPooledTransactionHashes { peer_id, msg })
131    }
132
133    /// Send full transactions to the peer
134    pub fn send_transactions(&self, peer_id: PeerId, msg: Vec<Arc<N::BroadcastedTransaction>>) {
135        self.send_message(NetworkHandleMessage::SendTransaction {
136            peer_id,
137            msg: SharedTransactions(msg),
138        })
139    }
140
141    /// Send eth message to the peer.
142    pub fn send_eth_message(&self, peer_id: PeerId, message: PeerMessage<N>) {
143        self.send_message(NetworkHandleMessage::EthMessage { peer_id, message })
144    }
145
146    /// Send message to get the [`TransactionsHandle`].
147    ///
148    /// Returns `None` if no transaction task is installed.
149    pub async fn transactions_handle(&self) -> Option<TransactionsHandle<N>> {
150        let (tx, rx) = oneshot::channel();
151        let _ = self.manager().send(NetworkHandleMessage::GetTransactionsHandle(tx));
152        rx.await.unwrap()
153    }
154
155    /// Send message to gracefully shutdown node.
156    ///
157    /// This will disconnect all active and pending sessions and prevent
158    /// new connections to be established.
159    pub async fn shutdown(&self) -> Result<(), oneshot::error::RecvError> {
160        let (tx, rx) = oneshot::channel();
161        self.send_message(NetworkHandleMessage::Shutdown(tx));
162        rx.await
163    }
164
165    /// Set network connection state to Active.
166    ///
167    /// New outbound connections will be established if there's capacity.
168    pub fn set_network_active(&self) {
169        self.set_network_conn(NetworkConnectionState::Active);
170    }
171
172    /// Set network connection state to Hibernate.
173    ///
174    /// No new outbound connections will be established.
175    pub fn set_network_hibernate(&self) {
176        self.set_network_conn(NetworkConnectionState::Hibernate);
177    }
178
179    /// Set network connection state.
180    fn set_network_conn(&self, network_conn: NetworkConnectionState) {
181        self.send_message(NetworkHandleMessage::SetNetworkState(network_conn));
182    }
183
184    /// Whether tx gossip is disabled
185    pub fn tx_gossip_disabled(&self) -> bool {
186        self.inner.tx_gossip_disabled
187    }
188
189    /// Returns the secret key used for authenticating sessions.
190    pub fn secret_key(&self) -> &SecretKey {
191        &self.inner.secret_key
192    }
193}
194
195// === API Implementations ===
196
197impl<N: NetworkPrimitives> NetworkPeersEvents for NetworkHandle<N> {
198    /// Returns an event stream of peer-specific network events.
199    fn peer_events(&self) -> PeerEventStream {
200        let peer_events = self.inner.event_sender.new_listener().map(|event| match event {
201            NetworkEvent::Peer(peer_event) => peer_event,
202            NetworkEvent::ActivePeerSession { info, .. } => PeerEvent::SessionEstablished(info),
203        });
204        PeerEventStream::new(peer_events)
205    }
206}
207
208impl<N: NetworkPrimitives> NetworkEventListenerProvider for NetworkHandle<N> {
209    type Primitives = N;
210
211    fn event_listener(&self) -> EventStream<NetworkEvent<PeerRequest<Self::Primitives>>> {
212        self.inner.event_sender.new_listener()
213    }
214
215    fn discovery_listener(&self) -> UnboundedReceiverStream<DiscoveryEvent> {
216        let (tx, rx) = mpsc::unbounded_channel();
217        let _ = self.manager().send(NetworkHandleMessage::DiscoveryListener(tx));
218        UnboundedReceiverStream::new(rx)
219    }
220}
221
222impl<N: NetworkPrimitives> NetworkProtocols for NetworkHandle<N> {
223    fn add_rlpx_sub_protocol(&self, protocol: RlpxSubProtocol) {
224        self.send_message(NetworkHandleMessage::AddRlpxSubProtocol(protocol))
225    }
226}
227
228impl<N: NetworkPrimitives> PeersInfo for NetworkHandle<N> {
229    fn num_connected_peers(&self) -> usize {
230        self.inner.num_active_peers.load(Ordering::Relaxed)
231    }
232
233    fn local_node_record(&self) -> NodeRecord {
234        if let Some(discv4) = &self.inner.discv4 {
235            // Note: the discv4 services uses the same `nat` so we can directly return the node
236            // record here
237            discv4.node_record()
238        } else if let Some(discv5) = self.inner.discv5.as_ref() {
239            // for disv5 we must check if we have an external ip configured
240            if let Some(external) =
241                self.inner.nat.clone().and_then(|nat| nat.as_external_ip(discv5.local_port()))
242            {
243                NodeRecord::new((external, discv5.local_port()).into(), *self.peer_id())
244            } else {
245                // use the node record that discv5 tracks or use localhost
246                self.inner.discv5.as_ref().and_then(|d| d.node_record()).unwrap_or_else(|| {
247                    NodeRecord::new(
248                        (std::net::IpAddr::V4(std::net::Ipv4Addr::LOCALHOST), discv5.local_port())
249                            .into(),
250                        *self.peer_id(),
251                    )
252                })
253            }
254            // also use the tcp port
255            .with_tcp_port(self.inner.listener_address.lock().port())
256        } else {
257            let mut socket_addr = *self.inner.listener_address.lock();
258
259            let external_ip =
260                self.inner.nat.clone().and_then(|nat| nat.as_external_ip(socket_addr.port()));
261
262            if let Some(ip) = external_ip {
263                // if able to resolve external ip, use it instead and also set the local address
264                socket_addr.set_ip(ip)
265            } else if socket_addr.ip().is_unspecified() {
266                // zero address is invalid
267                if socket_addr.ip().is_ipv4() {
268                    socket_addr.set_ip(std::net::IpAddr::V4(std::net::Ipv4Addr::LOCALHOST));
269                } else {
270                    socket_addr.set_ip(std::net::IpAddr::V6(std::net::Ipv6Addr::LOCALHOST));
271                }
272            }
273
274            NodeRecord::new(socket_addr, *self.peer_id())
275        }
276    }
277
278    fn local_enr(&self) -> Enr<SecretKey> {
279        let local_node_record = self.local_node_record();
280        let mut builder = Enr::builder();
281        builder.ip(local_node_record.address);
282        if local_node_record.address.is_ipv4() {
283            builder.udp4(local_node_record.udp_port);
284            builder.tcp4(local_node_record.tcp_port);
285        } else {
286            builder.udp6(local_node_record.udp_port);
287            builder.tcp6(local_node_record.tcp_port);
288        }
289        builder.build(&self.inner.secret_key).expect("valid enr")
290    }
291}
292
293impl<N: NetworkPrimitives> Peers for NetworkHandle<N> {
294    fn add_trusted_peer_id(&self, peer: PeerId) {
295        self.send_message(NetworkHandleMessage::AddTrustedPeerId(peer));
296    }
297
298    /// Sends a message to the [`NetworkManager`](crate::NetworkManager) to add a peer to the known
299    /// set, with the given kind.
300    fn add_peer_kind(
301        &self,
302        peer: PeerId,
303        kind: PeerKind,
304        tcp_addr: SocketAddr,
305        udp_addr: Option<SocketAddr>,
306    ) {
307        let addr = PeerAddr::new(tcp_addr, udp_addr);
308        self.send_message(NetworkHandleMessage::AddPeerAddress(peer, kind, addr));
309    }
310
311    async fn get_peers_by_kind(&self, kind: PeerKind) -> Result<Vec<PeerInfo>, NetworkError> {
312        let (tx, rx) = oneshot::channel();
313        let _ = self.manager().send(NetworkHandleMessage::GetPeerInfosByPeerKind(kind, tx));
314        Ok(rx.await?)
315    }
316
317    async fn get_all_peers(&self) -> Result<Vec<PeerInfo>, NetworkError> {
318        let (tx, rx) = oneshot::channel();
319        let _ = self.manager().send(NetworkHandleMessage::GetPeerInfos(tx));
320        Ok(rx.await?)
321    }
322
323    async fn get_peer_by_id(&self, peer_id: PeerId) -> Result<Option<PeerInfo>, NetworkError> {
324        let (tx, rx) = oneshot::channel();
325        let _ = self.manager().send(NetworkHandleMessage::GetPeerInfoById(peer_id, tx));
326        Ok(rx.await?)
327    }
328
329    async fn get_peers_by_id(&self, peer_ids: Vec<PeerId>) -> Result<Vec<PeerInfo>, NetworkError> {
330        let (tx, rx) = oneshot::channel();
331        let _ = self.manager().send(NetworkHandleMessage::GetPeerInfosByIds(peer_ids, tx));
332        Ok(rx.await?)
333    }
334
335    /// Sends a message to the [`NetworkManager`](crate::NetworkManager) to remove a peer from the
336    /// set corresponding to given kind.
337    fn remove_peer(&self, peer: PeerId, kind: PeerKind) {
338        self.send_message(NetworkHandleMessage::RemovePeer(peer, kind))
339    }
340
341    /// Sends a message to the [`NetworkManager`](crate::NetworkManager)  to disconnect an existing
342    /// connection to the given peer.
343    fn disconnect_peer(&self, peer: PeerId) {
344        self.send_message(NetworkHandleMessage::DisconnectPeer(peer, None))
345    }
346
347    /// Sends a message to the [`NetworkManager`](crate::NetworkManager)  to disconnect an existing
348    /// connection to the given peer using the provided reason
349    fn disconnect_peer_with_reason(&self, peer: PeerId, reason: DisconnectReason) {
350        self.send_message(NetworkHandleMessage::DisconnectPeer(peer, Some(reason)))
351    }
352
353    /// Sends a message to the [`NetworkManager`](crate::NetworkManager) to connect to the given
354    /// peer.
355    ///
356    /// This will add a new entry for the given peer if it isn't tracked yet.
357    /// If it is tracked then the peer is updated with the given information.
358    fn connect_peer_kind(
359        &self,
360        peer_id: PeerId,
361        kind: PeerKind,
362        tcp_addr: SocketAddr,
363        udp_addr: Option<SocketAddr>,
364    ) {
365        self.send_message(NetworkHandleMessage::ConnectPeer(
366            peer_id,
367            kind,
368            PeerAddr::new(tcp_addr, udp_addr),
369        ))
370    }
371
372    /// Send a reputation change for the given peer.
373    fn reputation_change(&self, peer_id: PeerId, kind: ReputationChangeKind) {
374        self.send_message(NetworkHandleMessage::ReputationChange(peer_id, kind));
375    }
376
377    async fn reputation_by_id(&self, peer_id: PeerId) -> Result<Option<Reputation>, NetworkError> {
378        let (tx, rx) = oneshot::channel();
379        let _ = self.manager().send(NetworkHandleMessage::GetReputationById(peer_id, tx));
380        Ok(rx.await?)
381    }
382}
383
384impl<N: NetworkPrimitives> PeersHandleProvider for NetworkHandle<N> {
385    fn peers_handle(&self) -> &PeersHandle {
386        &self.inner.peers
387    }
388}
389
390impl<N: NetworkPrimitives> NetworkInfo for NetworkHandle<N> {
391    fn local_addr(&self) -> SocketAddr {
392        *self.inner.listener_address.lock()
393    }
394
395    async fn network_status(&self) -> Result<NetworkStatus, NetworkError> {
396        let (tx, rx) = oneshot::channel();
397        let _ = self.manager().send(NetworkHandleMessage::GetStatus(tx));
398        rx.await.map_err(Into::into)
399    }
400
401    fn chain_id(&self) -> u64 {
402        self.inner.chain_id.load(Ordering::Relaxed)
403    }
404
405    fn is_syncing(&self) -> bool {
406        SyncStateProvider::is_syncing(self)
407    }
408
409    fn is_initially_syncing(&self) -> bool {
410        SyncStateProvider::is_initially_syncing(self)
411    }
412}
413
414impl<N: NetworkPrimitives> SyncStateProvider for NetworkHandle<N> {
415    fn is_syncing(&self) -> bool {
416        self.inner.is_syncing.load(Ordering::Relaxed)
417    }
418    // used to guard the txpool
419    fn is_initially_syncing(&self) -> bool {
420        if self.inner.initial_sync_done.load(Ordering::Relaxed) {
421            return false
422        }
423        self.inner.is_syncing.load(Ordering::Relaxed)
424    }
425}
426
427impl<N: NetworkPrimitives> NetworkSyncUpdater for NetworkHandle<N> {
428    fn update_sync_state(&self, state: SyncState) {
429        let future_state = state.is_syncing();
430        let prev_state = self.inner.is_syncing.swap(future_state, Ordering::Relaxed);
431        let syncing_to_idle_state_transition = prev_state && !future_state;
432        if syncing_to_idle_state_transition {
433            self.inner.initial_sync_done.store(true, Ordering::Relaxed);
434        }
435    }
436
437    /// Update the status of the node.
438    fn update_status(&self, head: Head) {
439        self.send_message(NetworkHandleMessage::StatusUpdate { head });
440    }
441
442    /// Updates the advertised block range.
443    fn update_block_range(&self, update: reth_eth_wire::BlockRangeUpdate) {
444        self.send_message(NetworkHandleMessage::InternalBlockRangeUpdate(update));
445    }
446}
447
448impl<N: NetworkPrimitives> BlockDownloaderProvider for NetworkHandle<N> {
449    type Client = FetchClient<N>;
450
451    async fn fetch_client(&self) -> Result<Self::Client, oneshot::error::RecvError> {
452        let (tx, rx) = oneshot::channel();
453        let _ = self.manager().send(NetworkHandleMessage::FetchClient(tx));
454        rx.await
455    }
456}
457
458#[derive(Debug)]
459struct NetworkInner<N: NetworkPrimitives = EthNetworkPrimitives> {
460    /// Number of active peer sessions the node's currently handling.
461    num_active_peers: Arc<AtomicUsize>,
462    /// Sender half of the message channel to the [`crate::NetworkManager`].
463    to_manager_tx: UnboundedSender<NetworkHandleMessage<N>>,
464    /// The local address that accepts incoming connections.
465    listener_address: Arc<Mutex<SocketAddr>>,
466    /// The secret key used for authenticating sessions.
467    secret_key: SecretKey,
468    /// The identifier used by this node.
469    local_peer_id: PeerId,
470    /// Access to all the nodes.
471    peers: PeersHandle,
472    /// The mode of the network
473    network_mode: NetworkMode,
474    /// Represents if the network is currently syncing.
475    is_syncing: Arc<AtomicBool>,
476    /// Used to differentiate between an initial pipeline sync or a live sync
477    initial_sync_done: Arc<AtomicBool>,
478    /// The chain id
479    chain_id: Arc<AtomicU64>,
480    /// Whether to disable transaction gossip
481    tx_gossip_disabled: bool,
482    /// The instance of the discv4 service
483    discv4: Option<Discv4>,
484    /// The instance of the discv5 service
485    discv5: Option<Discv5>,
486    /// Sender for high level network events.
487    event_sender: EventSender<NetworkEvent<PeerRequest<N>>>,
488    /// The NAT resolver
489    nat: Option<NatResolver>,
490}
491
492/// Provides access to modify the network's additional protocol handlers.
493pub trait NetworkProtocols: Send + Sync {
494    /// Adds an additional protocol handler to the `RLPx` sub-protocol list.
495    fn add_rlpx_sub_protocol(&self, protocol: RlpxSubProtocol);
496}
497
498/// Internal messages that can be passed to the  [`NetworkManager`](crate::NetworkManager).
499#[derive(Debug)]
500pub(crate) enum NetworkHandleMessage<N: NetworkPrimitives = EthNetworkPrimitives> {
501    /// Marks a peer as trusted.
502    AddTrustedPeerId(PeerId),
503    /// Adds an address for a peer, including its ID, kind, and socket address.
504    AddPeerAddress(PeerId, PeerKind, PeerAddr),
505    /// Removes a peer from the peerset corresponding to the given kind.
506    RemovePeer(PeerId, PeerKind),
507    /// Disconnects a connection to a peer if it exists, optionally providing a disconnect reason.
508    DisconnectPeer(PeerId, Option<DisconnectReason>),
509    /// Broadcasts an event to announce a new block to all nodes.
510    AnnounceBlock(N::NewBlockPayload, B256),
511    /// Sends a list of transactions to the given peer.
512    SendTransaction {
513        /// The ID of the peer to which the transactions are sent.
514        peer_id: PeerId,
515        /// The shared transactions to send.
516        msg: SharedTransactions<N::BroadcastedTransaction>,
517    },
518    /// Sends a list of transaction hashes to the given peer.
519    SendPooledTransactionHashes {
520        /// The ID of the peer to which the transaction hashes are sent.
521        peer_id: PeerId,
522        /// The new pooled transaction hashes to send.
523        msg: NewPooledTransactionHashes,
524    },
525    /// Sends an `eth` protocol request to the peer.
526    EthRequest {
527        /// The peer to send the request to.
528        peer_id: PeerId,
529        /// The request to send to the peer's sessions.
530        request: PeerRequest<N>,
531    },
532    /// Sends an `eth` protocol message to the peer.
533    EthMessage {
534        /// The peer to send the message to.
535        peer_id: PeerId,
536        /// The `eth` protocol message to send to the peer's session.
537        message: PeerMessage<N>,
538    },
539    /// Applies a reputation change to the given peer.
540    ReputationChange(PeerId, ReputationChangeKind),
541    /// Returns the client that can be used to interact with the network.
542    FetchClient(oneshot::Sender<FetchClient<N>>),
543    /// Applies a status update.
544    StatusUpdate {
545        /// The head status to apply.
546        head: Head,
547    },
548    /// Retrieves the current status via a oneshot sender.
549    GetStatus(oneshot::Sender<NetworkStatus>),
550    /// Gets `PeerInfo` for the specified peer IDs.
551    GetPeerInfosByIds(Vec<PeerId>, oneshot::Sender<Vec<PeerInfo>>),
552    /// Gets `PeerInfo` from all the peers via a oneshot sender.
553    GetPeerInfos(oneshot::Sender<Vec<PeerInfo>>),
554    /// Gets `PeerInfo` for a specific peer via a oneshot sender.
555    GetPeerInfoById(PeerId, oneshot::Sender<Option<PeerInfo>>),
556    /// Gets `PeerInfo` for a specific peer kind via a oneshot sender.
557    GetPeerInfosByPeerKind(PeerKind, oneshot::Sender<Vec<PeerInfo>>),
558    /// Gets the reputation for a specific peer via a oneshot sender.
559    GetReputationById(PeerId, oneshot::Sender<Option<Reputation>>),
560    /// Retrieves the `TransactionsHandle` via a oneshot sender.
561    GetTransactionsHandle(oneshot::Sender<Option<TransactionsHandle<N>>>),
562    /// Initiates a graceful shutdown of the network via a oneshot sender.
563    Shutdown(oneshot::Sender<()>),
564    /// Sets the network state between hibernation and active.
565    SetNetworkState(NetworkConnectionState),
566    /// Adds a new listener for `DiscoveryEvent`.
567    DiscoveryListener(UnboundedSender<DiscoveryEvent>),
568    /// Adds an additional `RlpxSubProtocol`.
569    AddRlpxSubProtocol(RlpxSubProtocol),
570    /// Connect to the given peer.
571    ConnectPeer(PeerId, PeerKind, PeerAddr),
572    /// Message to update the node's advertised block range information.
573    InternalBlockRangeUpdate(BlockRangeUpdate),
574}