snarkos_node/client/
router.rs

1// Copyright (c) 2019-2025 Provable Inc.
2// This file is part of the snarkOS library.
3
4// Licensed under the Apache License, Version 2.0 (the "License");
5// you may not use this file except in compliance with the License.
6// You may obtain a copy of the License at:
7
8// http://www.apache.org/licenses/LICENSE-2.0
9
10// Unless required by applicable law or agreed to in writing, software
11// distributed under the License is distributed on an "AS IS" BASIS,
12// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
13// See the License for the specific language governing permissions and
14// limitations under the License.
15
16use super::*;
17use snarkos_node_network::PeerPoolHandling;
18use snarkos_node_router::{
19    Routing,
20    messages::{
21        BlockRequest,
22        BlockResponse,
23        DataBlocks,
24        DisconnectReason,
25        MessageCodec,
26        PeerRequest,
27        Ping,
28        Pong,
29        PuzzleResponse,
30        UnconfirmedTransaction,
31    },
32};
33use snarkos_node_tcp::{Connection, ConnectionSide, Tcp};
34use snarkvm::{
35    console::network::{ConsensusVersion, Network},
36    ledger::{block::Transaction, narwhal::Data},
37    utilities::{log_error, log_warning},
38};
39
40use std::{io, net::SocketAddr};
41
42impl<N: Network, C: ConsensusStorage<N>> P2P for Client<N, C> {
43    /// Returns a reference to the TCP instance.
44    fn tcp(&self) -> &Tcp {
45        self.router.tcp()
46    }
47}
48
49#[async_trait]
50impl<N: Network, C: ConsensusStorage<N>> Handshake for Client<N, C> {
51    /// Performs the handshake protocol.
52    async fn perform_handshake(&self, mut connection: Connection) -> io::Result<Connection> {
53        // Perform the handshake.
54        let peer_addr = connection.addr();
55        let conn_side = connection.side();
56        let stream = self.borrow_stream(&mut connection);
57        let genesis_header = *self.genesis.header();
58        let restrictions_id = self.ledger.vm().restrictions().restrictions_id();
59        self.router.handshake(peer_addr, stream, conn_side, genesis_header, restrictions_id).await?;
60
61        Ok(connection)
62    }
63}
64
65#[async_trait]
66impl<N: Network, C: ConsensusStorage<N>> OnConnect for Client<N, C> {
67    async fn on_connect(&self, peer_addr: SocketAddr) {
68        // Resolve the peer address to the listener address.
69        if let Some(listener_addr) = self.router().resolve_to_listener(peer_addr) {
70            if let Some(peer) = self.router().get_connected_peer(listener_addr) {
71                // If it's a bootstrap client, only request its peers.
72                if peer.node_type == NodeType::BootstrapClient {
73                    self.router().send(listener_addr, Message::PeerRequest(PeerRequest));
74                } else {
75                    // Send the first `Ping` message to the peer.
76                    self.ping.on_peer_connected(listener_addr);
77                }
78            }
79        }
80    }
81}
82
83#[async_trait]
84impl<N: Network, C: ConsensusStorage<N>> Disconnect for Client<N, C> {
85    /// Any extra operations to be performed during a disconnect.
86    async fn handle_disconnect(&self, peer_addr: SocketAddr) {
87        if let Some(peer_ip) = self.router.resolve_to_listener(peer_addr) {
88            self.sync.remove_peer(&peer_ip);
89            self.router.downgrade_peer_to_candidate(peer_ip);
90            // Clear cached entries applicable to the peer.
91            self.router.cache().clear_peer_entries(peer_ip);
92            #[cfg(feature = "metrics")]
93            self.router.update_metrics();
94        }
95    }
96}
97
98#[async_trait]
99impl<N: Network, C: ConsensusStorage<N>> Reading for Client<N, C> {
100    type Codec = MessageCodec<N>;
101    type Message = Message<N>;
102
103    /// Creates a [`Decoder`] used to interpret messages from the network.
104    /// The `side` param indicates the connection side **from the node's perspective**.
105    fn codec(&self, _peer_addr: SocketAddr, _side: ConnectionSide) -> Self::Codec {
106        Default::default()
107    }
108
109    /// Processes a message received from the network.
110    async fn process_message(&self, peer_addr: SocketAddr, message: Self::Message) -> io::Result<()> {
111        let clone = self.clone();
112        if matches!(message, Message::BlockRequest(_) | Message::BlockResponse(_)) {
113            // Handle BlockRequest and BlockResponse messages in a separate task to not block the
114            // inbound queue.
115            tokio::spawn(async move {
116                clone.process_message_inner(peer_addr, message).await;
117            });
118        } else {
119            self.process_message_inner(peer_addr, message).await;
120        }
121        Ok(())
122    }
123}
124
125impl<N: Network, C: ConsensusStorage<N>> Client<N, C> {
126    async fn process_message_inner(
127        &self,
128        peer_addr: SocketAddr,
129        message: <Client<N, C> as snarkos_node_tcp::protocols::Reading>::Message,
130    ) {
131        // Process the message. Disconnect if the peer violated the protocol.
132        if let Err(error) = self.inbound(peer_addr, message).await {
133            warn!("Failed to process inbound message from '{peer_addr}' - {error}");
134            if let Some(peer_ip) = self.router().resolve_to_listener(peer_addr) {
135                warn!("Disconnecting from '{peer_ip}' for protocol violation");
136                self.router().send(peer_ip, Message::Disconnect(DisconnectReason::ProtocolViolation.into()));
137                // Disconnect from this peer.
138                self.router().disconnect(peer_ip);
139            }
140        }
141    }
142}
143
144#[async_trait]
145impl<N: Network, C: ConsensusStorage<N>> Routing<N> for Client<N, C> {}
146
147impl<N: Network, C: ConsensusStorage<N>> Heartbeat<N> for Client<N, C> {}
148
149impl<N: Network, C: ConsensusStorage<N>> Outbound<N> for Client<N, C> {
150    /// Returns a reference to the router.
151    fn router(&self) -> &Router<N> {
152        &self.router
153    }
154
155    /// Returns `true` if the node is synced up to the latest block (within the given tolerance).
156    fn is_block_synced(&self) -> bool {
157        self.sync.is_block_synced()
158    }
159
160    /// Returns the number of blocks this node is behind the greatest peer height,
161    /// or `None` if not connected to peers yet.
162    fn num_blocks_behind(&self) -> Option<u32> {
163        self.sync.num_blocks_behind()
164    }
165
166    /// Returns the current sync speed in blocks per second.
167    fn get_sync_speed(&self) -> f64 {
168        self.sync.get_sync_speed()
169    }
170}
171
172#[async_trait]
173impl<N: Network, C: ConsensusStorage<N>> Inbound<N> for Client<N, C> {
174    /// Returns `true` if the message version is valid.
175    fn is_valid_message_version(&self, message_version: u32) -> bool {
176        self.router().is_valid_message_version(message_version)
177    }
178
179    /// Handles a `BlockRequest` message.
180    fn block_request(&self, peer_ip: SocketAddr, message: BlockRequest) -> bool {
181        let BlockRequest { start_height, end_height } = &message;
182
183        // Get the latest consensus version, i.e., the one for the last block's height.
184        let latest_consensus_version = match N::CONSENSUS_VERSION(end_height.saturating_sub(1)) {
185            Ok(version) => version,
186            Err(err) => {
187                log_error(err.context("Failed to retrieve consensus version"));
188                return false;
189            }
190        };
191
192        // Retrieve the blocks within the requested range.
193        let blocks = match self.ledger.get_blocks(*start_height..*end_height) {
194            Ok(blocks) => DataBlocks(blocks),
195            Err(error) => {
196                error!("Failed to retrieve blocks {start_height} to {end_height} from the ledger - {error}");
197                return false;
198            }
199        };
200
201        // Send the `BlockResponse` message to the peer.
202        self.router()
203            .send(peer_ip, Message::BlockResponse(BlockResponse::new(message, blocks, latest_consensus_version)));
204        true
205    }
206
207    /// Handles a `BlockResponse` message.
208    fn block_response(
209        &self,
210        peer_ip: SocketAddr,
211        blocks: Vec<Block<N>>,
212        latest_consensus_version: Option<ConsensusVersion>,
213    ) -> bool {
214        // We do not need to explicitly sync here because insert_block_response, will wake up the sync task.
215        if let Err(err) = self.sync.insert_block_responses(peer_ip, blocks, latest_consensus_version) {
216            log_warning(err.context("Failed to insert block response"));
217            false
218        } else {
219            true
220        }
221    }
222
223    /// Processes the block locators and sends back a `Pong` message.
224    fn ping(&self, peer_ip: SocketAddr, message: Ping<N>) -> bool {
225        // If block locators were provided, then update the peer in the sync pool.
226        if let Some(block_locators) = message.block_locators {
227            // Check the block locators are valid, and update the peer in the sync pool.
228            if let Err(error) = self.sync.update_peer_locators(peer_ip, &block_locators) {
229                warn!("Peer '{peer_ip}' sent invalid block locators: {error}");
230                return false;
231            }
232
233            let last_peer_height = Some(block_locators.latest_locator_height());
234            self.router().update_connected_peer(&peer_ip, |peer| peer.last_height_seen = last_peer_height);
235        }
236
237        // Send a `Pong` message to the peer.
238        self.router().send(peer_ip, Message::Pong(Pong { is_fork: Some(false) }));
239        true
240    }
241
242    /// Sleeps for a period and then sends a `Ping` message to the peer.
243    fn pong(&self, peer_ip: SocketAddr, _message: Pong) -> bool {
244        self.ping.on_pong_received(peer_ip);
245        true
246    }
247
248    /// Retrieves the latest epoch hash and latest block header, and returns the puzzle response to the peer.
249    fn puzzle_request(&self, peer_ip: SocketAddr) -> bool {
250        // Retrieve the latest epoch hash.
251        let epoch_hash = match self.ledger.latest_epoch_hash() {
252            Ok(epoch_hash) => epoch_hash,
253            Err(error) => {
254                error!("Failed to prepare a puzzle request for '{peer_ip}': {error}");
255                return false;
256            }
257        };
258        // Retrieve the latest block header.
259        let block_header = Data::Object(self.ledger.latest_header());
260        // Send the `PuzzleResponse` message to the peer.
261        self.router().send(peer_ip, Message::PuzzleResponse(PuzzleResponse { epoch_hash, block_header }));
262        true
263    }
264
265    /// Saves the latest epoch hash and latest block header in the node.
266    fn puzzle_response(&self, peer_ip: SocketAddr, _epoch_hash: N::BlockHash, _header: Header<N>) -> bool {
267        debug!("Disconnecting '{peer_ip}' for the following reason - {:?}", DisconnectReason::ProtocolViolation);
268        false
269    }
270
271    /// Propagates the unconfirmed solution to all connected validators.
272    async fn unconfirmed_solution(
273        &self,
274        peer_ip: SocketAddr,
275        serialized: UnconfirmedSolution<N>,
276        solution: Solution<N>,
277    ) -> bool {
278        // Try to add the solution to the verification queue, without changing LRU status of known solutions.
279        let mut solution_queue = self.solution_queue.lock();
280        if !solution_queue.contains(&solution.id()) {
281            solution_queue.put(solution.id(), (peer_ip, serialized, solution));
282        }
283
284        true // Maintain the connection
285    }
286
287    /// Handles an `UnconfirmedTransaction` message.
288    async fn unconfirmed_transaction(
289        &self,
290        peer_ip: SocketAddr,
291        serialized: UnconfirmedTransaction<N>,
292        transaction: Transaction<N>,
293    ) -> bool {
294        // Try to add the transaction to a verification queue, without changing LRU status of known transactions.
295        match &transaction {
296            Transaction::<N>::Fee(..) => (), // Fee Transactions are not valid.
297            Transaction::<N>::Deploy(..) => {
298                let mut deploy_queue = self.deploy_queue.lock();
299                if !deploy_queue.contains(&transaction.id()) {
300                    deploy_queue.put(transaction.id(), (peer_ip, serialized, transaction));
301                }
302            }
303            Transaction::<N>::Execute(..) => {
304                let mut execute_queue = self.execute_queue.lock();
305                if !execute_queue.contains(&transaction.id()) {
306                    execute_queue.put(transaction.id(), (peer_ip, serialized, transaction));
307                }
308            }
309        }
310
311        true // Maintain the connection
312    }
313}