X-Git-Url: http://git.bitcoin.ninja/index.cgi?a=blobdiff_plain;f=lightning%2Fsrc%2Fln%2Fpeer_handler.rs;h=b99f2f522709dd56cbe01a5d441bb77f7892b255;hb=eff8af21103e43f763cb10ae6a75c1543a2d4068;hp=6576da806afb48c938791f47c0fee55880b5452a;hpb=b7f4f764afbe7105d9fa5f70e2c30c71ad90caa2;p=rust-lightning diff --git a/lightning/src/ln/peer_handler.rs b/lightning/src/ln/peer_handler.rs index 6576da80..b99f2f52 100644 --- a/lightning/src/ln/peer_handler.rs +++ b/lightning/src/ln/peer_handler.rs @@ -6,19 +6,19 @@ //! call into the provided message handlers (probably a ChannelManager and Router) with messages //! they should handle, and encoding/sending response messages. -use secp256k1::key::{SecretKey,PublicKey}; +use bitcoin::secp256k1::key::{SecretKey,PublicKey}; use ln::features::InitFeatures; use ln::msgs; use ln::msgs::ChannelMessageHandler; use ln::channelmanager::{SimpleArcChannelManager, SimpleRefChannelManager}; +use util::ser::VecWriter; use ln::peer_channel_encryptor::{PeerChannelEncryptor,NextNoiseStep}; use ln::wire; use ln::wire::Encode; use util::byte_utils; use util::events::{MessageSendEvent, MessageSendEventsProvider}; use util::logger::Logger; -use util::ser::Writer; use std::collections::{HashMap,hash_map,HashSet,LinkedList}; use std::sync::{Arc, Mutex}; @@ -26,9 +26,9 @@ use std::sync::atomic::{AtomicUsize, Ordering}; use std::{cmp,error,hash,fmt}; use std::ops::Deref; -use bitcoin_hashes::sha256::Hash as Sha256; -use bitcoin_hashes::sha256::HashEngine as Sha256Engine; -use bitcoin_hashes::{HashEngine, Hash}; +use bitcoin::hashes::sha256::Hash as Sha256; +use bitcoin::hashes::sha256::HashEngine as Sha256Engine; +use bitcoin::hashes::{HashEngine, Hash}; /// Provides references to trait impls which handle different types of messages. pub struct MessageHandler where CM::Target: msgs::ChannelMessageHandler { @@ -47,14 +47,15 @@ pub struct MessageHandler where CM::Target: msgs::ChannelMessageHandl /// For efficiency, Clone should be relatively cheap for this type. /// /// You probably want to just extend an int and put a file descriptor in a struct and implement -/// send_data. Note that if you are using a higher-level net library that may close() itself, be -/// careful to ensure you don't have races whereby you might register a new connection with an fd -/// the same as a yet-to-be-disconnect_event()-ed. +/// send_data. Note that if you are using a higher-level net library that may call close() itself, +/// be careful to ensure you don't have races whereby you might register a new connection with an +/// fd which is the same as a previous one which has yet to be removed via +/// PeerManager::socket_disconnected(). pub trait SocketDescriptor : cmp::Eq + hash::Hash + Clone { /// Attempts to send some data from the given slice to the peer. /// /// Returns the amount of data which was sent, possibly 0 if the socket has since disconnected. - /// Note that in the disconnected case, a disconnect_event must still fire and further write + /// Note that in the disconnected case, socket_disconnected must still fire and further write /// attempts may occur until that time. /// /// If the returned size is smaller than data.len(), a write_available event must @@ -67,17 +68,18 @@ pub trait SocketDescriptor : cmp::Eq + hash::Hash + Clone { /// *not* imply that further read events should be paused. fn send_data(&mut self, data: &[u8], resume_read: bool) -> usize; /// Disconnect the socket pointed to by this SocketDescriptor. Once this function returns, no - /// more calls to write_event, read_event or disconnect_event may be made with this descriptor. - /// No disconnect_event should be generated as a result of this call, though obviously races - /// may occur whereby disconnect_socket is called after a call to disconnect_event but prior to - /// that event completing. + /// more calls to write_buffer_space_avail, read_event or socket_disconnected may be made with + /// this descriptor. No socket_disconnected call should be generated as a result of this call, + /// though races may occur whereby disconnect_socket is called after a call to + /// socket_disconnected but prior to socket_disconnected returning. fn disconnect_socket(&mut self); } /// Error for PeerManager errors. If you get one of these, you must disconnect the socket and -/// generate no further read/write_events for the descriptor, only triggering a single -/// disconnect_event (unless it was provided in response to a new_*_connection event, in which case -/// no such disconnect_event must be generated and the socket be silently disconencted). +/// generate no further read_event/write_buffer_space_avail calls for the descriptor, only +/// triggering a single socket_disconnected call (unless it was provided in response to a +/// new_*_connection event, in which case no such socket_disconnected() must be called and the +/// socket silently disconencted). pub struct PeerHandleError { /// Used to indicate that we probably can't make any future connections to this peer, implying /// we should go ahead and force-close any channels we have with it. @@ -131,13 +133,22 @@ impl Peer { /// announcements/updates for the given channel_id then we will send it when we get to that /// point and we shouldn't send it yet to avoid sending duplicate updates. If we've already /// sent the old versions, we should send the update, and so return true here. - fn should_forward_channel(&self, channel_id: u64)->bool{ + fn should_forward_channel_announcement(&self, channel_id: u64)->bool{ match self.sync_status { InitSyncTracker::NoSyncRequested => true, InitSyncTracker::ChannelsSyncing(i) => i < channel_id, InitSyncTracker::NodesSyncing(_) => true, } } + + /// Similar to the above, but for node announcements indexed by node_id. + fn should_forward_node_announcement(&self, node_id: PublicKey) -> bool { + match self.sync_status { + InitSyncTracker::NoSyncRequested => true, + InitSyncTracker::ChannelsSyncing(_) => false, + InitSyncTracker::NodesSyncing(pk) => pk < node_id, + } + } } struct PeerHolder { @@ -160,7 +171,7 @@ fn _check_usize_is_32_or_64() { /// lifetimes). Other times you can afford a reference, which is more efficient, in which case /// SimpleRefPeerManager is the more appropriate type. Defining these type aliases prevents /// issues such as overly long function definitions. -pub type SimpleArcPeerManager = Arc>>; +pub type SimpleArcPeerManager = Arc>>; /// SimpleRefPeerManager is a type alias for a PeerManager reference, and is the reference /// counterpart to the SimpleArcPeerManager type alias. Use this type by default when you don't @@ -168,7 +179,7 @@ pub type SimpleArcPeerManager = Arc = PeerManager>; +pub type SimpleRefPeerManager<'a, 'b, 'c, 'd, SD, M, T, F> = PeerManager>; /// A PeerManager manages a set of peers, described by their SocketDescriptor and marshalls socket /// events into messages which it passes on to its MessageHandlers. @@ -192,17 +203,6 @@ pub struct PeerManager where CM::Target logger: Arc, } -struct VecWriter(Vec); -impl Writer for VecWriter { - fn write_all(&mut self, buf: &[u8]) -> Result<(), ::std::io::Error> { - self.0.extend_from_slice(buf); - Ok(()) - } - fn size_hint(&mut self, size: usize) { - self.0.reserve_exact(size); - } -} - macro_rules! encode_msg { ($msg: expr) => {{ let mut buffer = VecWriter(Vec::new()); @@ -212,7 +212,7 @@ macro_rules! encode_msg { } /// Manages and reacts to connection events. You probably want to use file descriptors as PeerIds. -/// PeerIds may repeat, but only after disconnect_event() has been called. +/// PeerIds may repeat, but only after socket_disconnected() has been called. impl PeerManager where CM::Target: msgs::ChannelMessageHandler { /// Constructs a new PeerManager with the given message handlers and node_id secret key /// ephemeral_random_data is used to derive per-connection ephemeral keys and must be @@ -265,13 +265,13 @@ impl PeerManager where } /// Indicates a new outbound connection has been established to a node with the given node_id. - /// Note that if an Err is returned here you MUST NOT call disconnect_event for the new + /// Note that if an Err is returned here you MUST NOT call socket_disconnected for the new /// descriptor but must disconnect the connection immediately. /// /// Returns a small number of bytes to send to the remote node (currently always 50). /// - /// Panics if descriptor is duplicative with some other descriptor which has not yet has a - /// disconnect_event. + /// Panics if descriptor is duplicative with some other descriptor which has not yet had a + /// socket_disconnected(). pub fn new_outbound_connection(&self, their_node_id: PublicKey, descriptor: Descriptor) -> Result, PeerHandleError> { let mut peer_encryptor = PeerChannelEncryptor::new_outbound(their_node_id.clone(), self.get_ephemeral_key()); let res = peer_encryptor.get_act_one().to_vec(); @@ -305,11 +305,11 @@ impl PeerManager where /// /// May refuse the connection by returning an Err, but will never write bytes to the remote end /// (outbound connector always speaks first). Note that if an Err is returned here you MUST NOT - /// call disconnect_event for the new descriptor but must disconnect the connection + /// call socket_disconnected for the new descriptor but must disconnect the connection /// immediately. /// - /// Panics if descriptor is duplicative with some other descriptor which has not yet has a - /// disconnect_event. + /// Panics if descriptor is duplicative with some other descriptor which has not yet had + /// socket_disconnected called. pub fn new_inbound_connection(&self, descriptor: Descriptor) -> Result<(), PeerHandleError> { let peer_encryptor = PeerChannelEncryptor::new_inbound(&self.our_node_secret); let pending_read_buffer = [0; 50].to_vec(); // Noise act one is 50 bytes @@ -354,11 +354,15 @@ impl PeerManager where InitSyncTracker::NoSyncRequested => {}, InitSyncTracker::ChannelsSyncing(c) if c < 0xffff_ffff_ffff_ffff => { let steps = ((MSG_BUFF_SIZE - peer.pending_outbound_buffer.len() + 2) / 3) as u8; - let all_messages = self.message_handler.route_handler.get_next_channel_announcements(0, steps); - for &(ref announce, ref update_a, ref update_b) in all_messages.iter() { + let all_messages = self.message_handler.route_handler.get_next_channel_announcements(c, steps); + for &(ref announce, ref update_a_option, ref update_b_option) in all_messages.iter() { encode_and_send_msg!(announce); - encode_and_send_msg!(update_a); - encode_and_send_msg!(update_b); + if let &Some(ref update_a) = update_a_option { + encode_and_send_msg!(update_a); + } + if let &Some(ref update_b) = update_b_option { + encode_and_send_msg!(update_b); + } peer.sync_status = InitSyncTracker::ChannelsSyncing(announce.contents.short_channel_id + 1); } if all_messages.is_empty() || all_messages.len() != steps as usize { @@ -417,10 +421,11 @@ impl PeerManager where /// /// Will most likely call send_data on the descriptor passed in (or the descriptor handed into /// new_*\_connection) before returning. Thus, be very careful with reentrancy issues! The - /// invariants around calling write_event in case a write did not fully complete must still - /// hold - be ready to call write_event again if a write call generated here isn't sufficient! - /// Panics if the descriptor was not previously registered in a new_\*_connection event. - pub fn write_event(&self, descriptor: &mut Descriptor) -> Result<(), PeerHandleError> { + /// invariants around calling write_buffer_space_avail in case a write did not fully complete + /// must still hold - be ready to call write_buffer_space_avail again if a write call generated + /// here isn't sufficient! Panics if the descriptor was not previously registered in a + /// new_\*_connection event. + pub fn write_buffer_space_avail(&self, descriptor: &mut Descriptor) -> Result<(), PeerHandleError> { let mut peers = self.peers.lock().unwrap(); match peers.peers.get_mut(descriptor) { None => panic!("Descriptor for write_event is not already known to PeerManager"), @@ -440,11 +445,11 @@ impl PeerManager where /// Thus, however, you almost certainly want to call process_events() after any read_event to /// generate send_data calls to handle responses. /// - /// If Ok(true) is returned, further read_events should not be triggered until a write_event on - /// this file descriptor has resume_read set (preventing DoS issues in the send buffer). + /// If Ok(true) is returned, further read_events should not be triggered until a send_data call + /// on this file descriptor has resume_read set (preventing DoS issues in the send buffer). /// /// Panics if the descriptor was not previously registered in a new_*_connection event. - pub fn read_event(&self, peer_descriptor: &mut Descriptor, data: Vec) -> Result { + pub fn read_event(&self, peer_descriptor: &mut Descriptor, data: &[u8]) -> Result { match self.do_read_event(peer_descriptor, data) { Ok(res) => Ok(res), Err(e) => { @@ -454,7 +459,7 @@ impl PeerManager where } } - fn do_read_event(&self, peer_descriptor: &mut Descriptor, data: Vec) -> Result { + fn do_read_event(&self, peer_descriptor: &mut Descriptor, data: &[u8]) -> Result { let pause_read = { let mut peers_lock = self.peers.lock().unwrap(); let peers = &mut *peers_lock; @@ -594,10 +599,6 @@ impl PeerManager where log_debug!(self, "Deserialization failed due to shortness of message"); return Err(PeerHandleError { no_connection_possible: false }); } - msgs::DecodeError::ExtraAddressesPerType => { - log_debug!(self, "Error decoding message, ignoring due to lnd spec incompatibility. See https://github.com/lightningnetwork/lnd/issues/1407"); - continue; - } msgs::DecodeError::BadLengthDescriptor => return Err(PeerHandleError { no_connection_possible: false }), msgs::DecodeError::Io(_) => return Err(PeerHandleError { no_connection_possible: false }), } @@ -763,10 +764,13 @@ impl PeerManager where // Unknown messages: wire::Message::Unknown(msg_type) if msg_type.is_even() => { + log_debug!(self, "Received unknown even message of type {}, disconnecting peer!", msg_type); // Fail the channel if message is an even, unknown type as per BOLT #1. return Err(PeerHandleError{ no_connection_possible: true }); }, - wire::Message::Unknown(_) => {}, + wire::Message::Unknown(msg_type) => { + log_trace!(self, "Received unknown odd message of type {}, ignoring", msg_type); + }, } } } @@ -963,7 +967,7 @@ impl PeerManager where for (ref descriptor, ref mut peer) in peers.peers.iter_mut() { if !peer.channel_encryptor.is_ready_for_encryption() || peer.their_features.is_none() || - !peer.should_forward_channel(msg.contents.short_channel_id) { + !peer.should_forward_channel_announcement(msg.contents.short_channel_id) { continue } match peer.their_node_id { @@ -980,6 +984,21 @@ impl PeerManager where } } }, + MessageSendEvent::BroadcastNodeAnnouncement { ref msg } => { + log_trace!(self, "Handling BroadcastNodeAnnouncement event in peer_handler"); + if self.message_handler.route_handler.handle_node_announcement(msg).is_ok() { + let encoded_msg = encode_msg!(msg); + + for (ref descriptor, ref mut peer) in peers.peers.iter_mut() { + if !peer.channel_encryptor.is_ready_for_encryption() || peer.their_features.is_none() || + !peer.should_forward_node_announcement(msg.contents.node_id) { + continue + } + peer.pending_outbound_buffer.push_back(peer.channel_encryptor.encrypt_message(&encoded_msg[..])); + self.do_attempt_write_data(&mut (*descriptor).clone(), peer); + } + } + }, MessageSendEvent::BroadcastChannelUpdate { ref msg } => { log_trace!(self, "Handling BroadcastChannelUpdate event in peer_handler for short channel id {}", msg.contents.short_channel_id); if self.message_handler.route_handler.handle_channel_update(msg).is_ok() { @@ -987,7 +1006,7 @@ impl PeerManager where for (ref descriptor, ref mut peer) in peers.peers.iter_mut() { if !peer.channel_encryptor.is_ready_for_encryption() || peer.their_features.is_none() || - !peer.should_forward_channel(msg.contents.short_channel_id) { + !peer.should_forward_channel_announcement(msg.contents.short_channel_id) { continue } peer.pending_outbound_buffer.push_back(peer.channel_encryptor.encrypt_message(&encoded_msg[..])); @@ -1047,11 +1066,13 @@ impl PeerManager where /// Indicates that the given socket descriptor's connection is now closed. /// - /// This must be called even if a PeerHandleError was given for a read_event or write_event, - /// but must NOT be called if a PeerHandleError was provided out of a new_\*\_connection event! + /// This must only be called if the socket has been disconnected by the peer or your own + /// decision to disconnect it and must NOT be called in any case where other parts of this + /// library (eg PeerHandleError, explicit disconnect_socket calls) instruct you to disconnect + /// the peer. /// /// Panics if the descriptor was not previously registered in a successful new_*_connection event. - pub fn disconnect_event(&self, descriptor: &Descriptor) { + pub fn socket_disconnected(&self, descriptor: &Descriptor) { self.disconnect_event_internal(descriptor, false); } @@ -1084,60 +1105,95 @@ impl PeerManager where let peers_needing_send = &mut peers.peers_needing_send; let node_id_to_descriptor = &mut peers.node_id_to_descriptor; let peers = &mut peers.peers; + let mut descriptors_needing_disconnect = Vec::new(); peers.retain(|descriptor, peer| { - if peer.awaiting_pong == true { + if peer.awaiting_pong { peers_needing_send.remove(descriptor); + descriptors_needing_disconnect.push(descriptor.clone()); match peer.their_node_id { Some(node_id) => { + log_trace!(self, "Disconnecting peer with id {} due to ping timeout", node_id); node_id_to_descriptor.remove(&node_id); - self.message_handler.chan_handler.peer_disconnected(&node_id, true); + self.message_handler.chan_handler.peer_disconnected(&node_id, false); + } + None => { + // This can't actually happen as we should have hit + // is_ready_for_encryption() previously on this same peer. + unreachable!(); }, - None => {} } + return false; + } + + if !peer.channel_encryptor.is_ready_for_encryption() { + // The peer needs to complete its handshake before we can exchange messages + return true; } let ping = msgs::Ping { ponglen: 0, byteslen: 64, }; - peer.pending_outbound_buffer.push_back(encode_msg!(&ping)); + peer.pending_outbound_buffer.push_back(peer.channel_encryptor.encrypt_message(&encode_msg!(&ping))); + let mut descriptor_clone = descriptor.clone(); self.do_attempt_write_data(&mut descriptor_clone, peer); - if peer.awaiting_pong { - false // Drop the peer - } else { - peer.awaiting_pong = true; - true - } + peer.awaiting_pong = true; + true }); + + for mut descriptor in descriptors_needing_disconnect.drain(..) { + descriptor.disconnect_socket(); + } } } } #[cfg(test)] mod tests { + use bitcoin::secp256k1::Signature; + use bitcoin::BitcoinHash; + use bitcoin::network::constants::Network; + use bitcoin::blockdata::constants::genesis_block; use ln::peer_handler::{PeerManager, MessageHandler, SocketDescriptor}; use ln::msgs; + use ln::features::ChannelFeatures; use util::events; use util::test_utils; use util::logger::Logger; - use secp256k1::Secp256k1; - use secp256k1::key::{SecretKey, PublicKey}; + use bitcoin::secp256k1::Secp256k1; + use bitcoin::secp256k1::key::{SecretKey, PublicKey}; use rand::{thread_rng, Rng}; - use std::sync::{Arc}; + use std; + use std::cmp::min; + use std::sync::{Arc, Mutex}; + use std::sync::atomic::{AtomicUsize, Ordering}; - #[derive(PartialEq, Eq, Clone, Hash)] + #[derive(Clone)] struct FileDescriptor { fd: u16, + outbound_data: Arc>>, + } + impl PartialEq for FileDescriptor { + fn eq(&self, other: &Self) -> bool { + self.fd == other.fd + } + } + impl Eq for FileDescriptor { } + impl std::hash::Hash for FileDescriptor { + fn hash(&self, hasher: &mut H) { + self.fd.hash(hasher) + } } impl SocketDescriptor for FileDescriptor { fn send_data(&mut self, data: &[u8], _resume_read: bool) -> usize { + self.outbound_data.lock().unwrap().extend_from_slice(data); data.len() } @@ -1154,7 +1210,7 @@ mod tests { chan_handlers } - fn create_network<'a>(peer_count: usize, chan_handlers: &'a Vec) -> Vec> { + fn create_network<'a>(peer_count: usize, chan_handlers: &'a Vec, routing_handlers: Option<&'a Vec>>) -> Vec> { let mut peers = Vec::new(); let mut rng = thread_rng(); let logger : Arc = Arc::new(test_utils::TestLogger::new()); @@ -1162,13 +1218,15 @@ mod tests { rng.fill_bytes(&mut ephemeral_bytes); for i in 0..peer_count { - let router = test_utils::TestRoutingMessageHandler::new(); + let router = if let Some(routers) = routing_handlers { routers[i].clone() } else { + Arc::new(test_utils::TestRoutingMessageHandler::new()) + }; let node_id = { let mut key_slice = [0;32]; rng.fill_bytes(&mut key_slice); SecretKey::from_slice(&key_slice).unwrap() }; - let msg_handler = MessageHandler { chan_handler: &chan_handlers[i], route_handler: Arc::new(router) }; + let msg_handler = MessageHandler { chan_handler: &chan_handlers[i], route_handler: router }; let peer = PeerManager::new(msg_handler, node_id, &ephemeral_bytes, Arc::clone(&logger)); peers.push(peer); } @@ -1176,12 +1234,17 @@ mod tests { peers } - fn establish_connection<'a>(peer_a: &PeerManager, peer_b: &PeerManager) { + fn establish_connection<'a>(peer_a: &PeerManager, peer_b: &PeerManager) -> (FileDescriptor, FileDescriptor) { let secp_ctx = Secp256k1::new(); - let their_id = PublicKey::from_secret_key(&secp_ctx, &peer_b.our_node_secret); - let fd = FileDescriptor { fd: 1}; - peer_a.new_inbound_connection(fd.clone()).unwrap(); - peer_a.peers.lock().unwrap().node_id_to_descriptor.insert(their_id, fd.clone()); + let a_id = PublicKey::from_secret_key(&secp_ctx, &peer_a.our_node_secret); + let mut fd_a = FileDescriptor { fd: 1, outbound_data: Arc::new(Mutex::new(Vec::new())) }; + let mut fd_b = FileDescriptor { fd: 1, outbound_data: Arc::new(Mutex::new(Vec::new())) }; + let initial_data = peer_b.new_outbound_connection(a_id, fd_b.clone()).unwrap(); + peer_a.new_inbound_connection(fd_a.clone()).unwrap(); + assert_eq!(peer_a.read_event(&mut fd_a, &initial_data).unwrap(), false); + assert_eq!(peer_b.read_event(&mut fd_b, &fd_a.outbound_data.lock().unwrap().split_off(0)).unwrap(), false); + assert_eq!(peer_a.read_event(&mut fd_a, &fd_b.outbound_data.lock().unwrap().split_off(0)).unwrap(), false); + (fd_a.clone(), fd_b.clone()) } #[test] @@ -1190,7 +1253,7 @@ mod tests { // push a DisconnectPeer event to remove the node flagged by id let chan_handlers = create_chan_handlers(2); let chan_handler = test_utils::TestChannelMessageHandler::new(); - let mut peers = create_network(2, &chan_handlers); + let mut peers = create_network(2, &chan_handlers, None); establish_connection(&peers[0], &peers[1]); assert_eq!(peers[0].peers.lock().unwrap().peers.len(), 1); @@ -1207,11 +1270,12 @@ mod tests { peers[0].process_events(); assert_eq!(peers[0].peers.lock().unwrap().peers.len(), 0); } + #[test] - fn test_timer_tick_occured(){ + fn test_timer_tick_occurred() { // Create peers, a vector of two peer managers, perform initial set up and check that peers[0] has one Peer. let chan_handlers = create_chan_handlers(2); - let peers = create_network(2, &chan_handlers); + let peers = create_network(2, &chan_handlers, None); establish_connection(&peers[0], &peers[1]); assert_eq!(peers[0].peers.lock().unwrap().peers.len(), 1); @@ -1223,4 +1287,138 @@ mod tests { peers[0].timer_tick_occured(); assert_eq!(peers[0].peers.lock().unwrap().peers.len(), 0); } + + pub struct TestRoutingMessageHandler { + pub chan_upds_recvd: AtomicUsize, + pub chan_anns_recvd: AtomicUsize, + pub chan_anns_sent: AtomicUsize, + } + + impl TestRoutingMessageHandler { + pub fn new() -> Self { + TestRoutingMessageHandler { + chan_upds_recvd: AtomicUsize::new(0), + chan_anns_recvd: AtomicUsize::new(0), + chan_anns_sent: AtomicUsize::new(0), + } + } + + } + impl msgs::RoutingMessageHandler for TestRoutingMessageHandler { + fn handle_node_announcement(&self, _msg: &msgs::NodeAnnouncement) -> Result { + Err(msgs::LightningError { err: "", action: msgs::ErrorAction::IgnoreError }) + } + fn handle_channel_announcement(&self, _msg: &msgs::ChannelAnnouncement) -> Result { + self.chan_anns_recvd.fetch_add(1, Ordering::AcqRel); + Err(msgs::LightningError { err: "", action: msgs::ErrorAction::IgnoreError }) + } + fn handle_channel_update(&self, _msg: &msgs::ChannelUpdate) -> Result { + self.chan_upds_recvd.fetch_add(1, Ordering::AcqRel); + Err(msgs::LightningError { err: "", action: msgs::ErrorAction::IgnoreError }) + } + fn handle_htlc_fail_channel_update(&self, _update: &msgs::HTLCFailChannelUpdate) {} + fn get_next_channel_announcements(&self, starting_point: u64, batch_amount: u8) -> Vec<(msgs::ChannelAnnouncement, Option, Option)> { + let mut chan_anns = Vec::new(); + const TOTAL_UPDS: u64 = 100; + let end: u64 = min(starting_point + batch_amount as u64, TOTAL_UPDS - self.chan_anns_sent.load(Ordering::Acquire) as u64); + for i in starting_point..end { + let chan_upd_1 = get_dummy_channel_update(i); + let chan_upd_2 = get_dummy_channel_update(i); + let chan_ann = get_dummy_channel_announcement(i); + + chan_anns.push((chan_ann, Some(chan_upd_1), Some(chan_upd_2))); + } + + self.chan_anns_sent.fetch_add(chan_anns.len(), Ordering::AcqRel); + chan_anns + } + + fn get_next_node_announcements(&self, _starting_point: Option<&PublicKey>, _batch_amount: u8) -> Vec { + Vec::new() + } + + fn should_request_full_sync(&self, _node_id: &PublicKey) -> bool { + true + } + } + + fn get_dummy_channel_announcement(short_chan_id: u64) -> msgs::ChannelAnnouncement { + use bitcoin::secp256k1::ffi::Signature as FFISignature; + let secp_ctx = Secp256k1::new(); + let network = Network::Testnet; + let node_1_privkey = SecretKey::from_slice(&[42; 32]).unwrap(); + let node_2_privkey = SecretKey::from_slice(&[41; 32]).unwrap(); + let node_1_btckey = SecretKey::from_slice(&[40; 32]).unwrap(); + let node_2_btckey = SecretKey::from_slice(&[39; 32]).unwrap(); + let unsigned_ann = msgs::UnsignedChannelAnnouncement { + features: ChannelFeatures::supported(), + chain_hash: genesis_block(network).header.bitcoin_hash(), + short_channel_id: short_chan_id, + node_id_1: PublicKey::from_secret_key(&secp_ctx, &node_1_privkey), + node_id_2: PublicKey::from_secret_key(&secp_ctx, &node_2_privkey), + bitcoin_key_1: PublicKey::from_secret_key(&secp_ctx, &node_1_btckey), + bitcoin_key_2: PublicKey::from_secret_key(&secp_ctx, &node_2_btckey), + excess_data: Vec::new(), + }; + + msgs::ChannelAnnouncement { + node_signature_1: Signature::from(FFISignature::new()), + node_signature_2: Signature::from(FFISignature::new()), + bitcoin_signature_1: Signature::from(FFISignature::new()), + bitcoin_signature_2: Signature::from(FFISignature::new()), + contents: unsigned_ann, + } + } + + fn get_dummy_channel_update(short_chan_id: u64) -> msgs::ChannelUpdate { + use bitcoin::secp256k1::ffi::Signature as FFISignature; + let network = Network::Testnet; + msgs::ChannelUpdate { + signature: Signature::from(FFISignature::new()), + contents: msgs::UnsignedChannelUpdate { + chain_hash: genesis_block(network).header.bitcoin_hash(), + short_channel_id: short_chan_id, + timestamp: 0, + flags: 0, + cltv_expiry_delta: 0, + htlc_minimum_msat: 0, + fee_base_msat: 0, + fee_proportional_millionths: 0, + excess_data: vec![], + } + } + } + + #[test] + fn test_do_attempt_write_data() { + // Create 2 peers with custom TestRoutingMessageHandlers and connect them. + let chan_handlers = create_chan_handlers(2); + let mut routing_handlers: Vec> = Vec::new(); + let mut routing_handlers_concrete: Vec> = Vec::new(); + for _ in 0..2 { + let routing_handler = Arc::new(TestRoutingMessageHandler::new()); + routing_handlers.push(routing_handler.clone()); + routing_handlers_concrete.push(routing_handler.clone()); + } + let peers = create_network(2, &chan_handlers, Some(&routing_handlers)); + + // By calling establish_connect, we trigger do_attempt_write_data between + // the peers. Previously this function would mistakenly enter an infinite loop + // when there were more channel messages available than could fit into a peer's + // buffer. This issue would now be detected by this test (because we use custom + // RoutingMessageHandlers that intentionally return more channel messages + // than can fit into a peer's buffer). + let (mut fd_a, mut fd_b) = establish_connection(&peers[0], &peers[1]); + + // Make each peer to read the messages that the other peer just wrote to them. + peers[1].read_event(&mut fd_b, &fd_a.outbound_data.lock().unwrap().split_off(0)).unwrap(); + peers[0].read_event(&mut fd_a, &fd_b.outbound_data.lock().unwrap().split_off(0)).unwrap(); + + // Check that each peer has received the expected number of channel updates and channel + // announcements. + assert_eq!(routing_handlers_concrete[0].clone().chan_upds_recvd.load(Ordering::Acquire), 100); + assert_eq!(routing_handlers_concrete[0].clone().chan_anns_recvd.load(Ordering::Acquire), 50); + assert_eq!(routing_handlers_concrete[1].clone().chan_upds_recvd.load(Ordering::Acquire), 100); + assert_eq!(routing_handlers_concrete[1].clone().chan_anns_recvd.load(Ordering::Acquire), 50); + } }