2020-12-02 17:10:07 +00:00
|
|
|
use std::any::Any;
|
2020-12-02 12:30:47 +00:00
|
|
|
use std::collections::HashMap;
|
2020-12-11 14:53:59 +00:00
|
|
|
use std::net::{IpAddr, SocketAddr};
|
2020-12-02 12:30:47 +00:00
|
|
|
use std::pin::Pin;
|
|
|
|
use std::sync::{Arc, RwLock};
|
2020-12-07 17:07:55 +00:00
|
|
|
use std::time::Instant;
|
2020-12-02 12:30:47 +00:00
|
|
|
|
|
|
|
use std::future::Future;
|
|
|
|
|
|
|
|
use log::{debug, info};
|
|
|
|
|
|
|
|
use arc_swap::{ArcSwap, ArcSwapOption};
|
|
|
|
use bytes::Bytes;
|
|
|
|
|
|
|
|
use sodiumoxide::crypto::auth;
|
|
|
|
use sodiumoxide::crypto::sign::ed25519;
|
|
|
|
use tokio::net::{TcpListener, TcpStream};
|
|
|
|
|
|
|
|
use crate::conn::*;
|
|
|
|
use crate::error::*;
|
|
|
|
use crate::message::*;
|
|
|
|
use crate::proto::*;
|
|
|
|
use crate::util::*;
|
|
|
|
|
2020-12-02 17:10:07 +00:00
|
|
|
type DynMsg = Box<dyn Any + Send + Sync + 'static>;
|
|
|
|
|
2021-10-12 11:18:24 +00:00
|
|
|
type OnConnectHandler = Box<dyn Fn(NodeID, SocketAddr, bool) + Send + Sync>;
|
|
|
|
type OnDisconnectHandler = Box<dyn Fn(NodeID, bool) + Send + Sync>;
|
|
|
|
|
2021-10-12 11:33:42 +00:00
|
|
|
pub(crate) type LocalHandler =
|
|
|
|
Box<dyn Fn(DynMsg) -> Pin<Box<dyn Future<Output = DynMsg> + Sync + Send>> + Sync + Send>;
|
2021-10-12 11:18:24 +00:00
|
|
|
pub(crate) type NetHandler = Box<
|
2021-10-12 11:33:42 +00:00
|
|
|
dyn Fn(NodeID, Bytes) -> Pin<Box<dyn Future<Output = Vec<u8>> + Sync + Send>> + Sync + Send,
|
|
|
|
>;
|
2021-10-12 11:18:24 +00:00
|
|
|
|
2020-12-02 17:10:07 +00:00
|
|
|
pub(crate) struct Handler {
|
2021-10-12 11:18:24 +00:00
|
|
|
pub(crate) local_handler: LocalHandler,
|
|
|
|
pub(crate) net_handler: NetHandler,
|
2020-12-02 17:10:07 +00:00
|
|
|
}
|
|
|
|
|
2020-12-02 19:12:24 +00:00
|
|
|
/// NetApp is the main class that handles incoming and outgoing connections.
|
|
|
|
///
|
|
|
|
/// The `request()` method can be used to send a message to any peer to which we have
|
|
|
|
/// an outgoing connection, or to ourself. On the server side, these messages are
|
|
|
|
/// processed by the handlers that have been defined using `add_msg_handler()`.
|
|
|
|
///
|
2021-10-12 11:18:24 +00:00
|
|
|
/// NetApp can be used in a stand-alone fashion or together with a peering strategy.
|
|
|
|
/// If using it alone, you will want to set `on_connect` and `on_disconnect` events
|
|
|
|
/// in order to manage information about the current peer list.
|
2020-12-02 19:12:24 +00:00
|
|
|
///
|
|
|
|
/// It is generally not necessary to use NetApp stand-alone, as the provided full mesh
|
|
|
|
/// and RPS peering strategies take care of the most common use cases.
|
2020-12-02 12:30:47 +00:00
|
|
|
pub struct NetApp {
|
2020-12-12 18:27:18 +00:00
|
|
|
listen_params: ArcSwapOption<ListenParams>,
|
2020-12-11 14:53:59 +00:00
|
|
|
|
2020-12-12 20:14:15 +00:00
|
|
|
/// Network secret key
|
2020-12-02 12:30:47 +00:00
|
|
|
pub netid: auth::Key,
|
2020-12-12 20:14:15 +00:00
|
|
|
/// Our peer ID
|
|
|
|
pub id: NodeID,
|
|
|
|
/// Private key associated with our peer ID
|
2020-12-02 12:30:47 +00:00
|
|
|
pub privkey: ed25519::SecretKey,
|
2020-12-02 19:12:24 +00:00
|
|
|
|
2020-12-12 20:14:15 +00:00
|
|
|
server_conns: RwLock<HashMap<NodeID, Arc<ServerConn>>>,
|
|
|
|
client_conns: RwLock<HashMap<NodeID, Arc<ClientConn>>>,
|
2020-12-07 12:35:24 +00:00
|
|
|
|
2020-12-02 17:10:07 +00:00
|
|
|
pub(crate) msg_handlers: ArcSwap<HashMap<MessageKind, Arc<Handler>>>,
|
2021-10-12 11:18:24 +00:00
|
|
|
on_connected_handler: ArcSwapOption<OnConnectHandler>,
|
|
|
|
on_disconnected_handler: ArcSwapOption<OnDisconnectHandler>,
|
2020-12-02 12:30:47 +00:00
|
|
|
}
|
|
|
|
|
2020-12-12 18:27:18 +00:00
|
|
|
struct ListenParams {
|
|
|
|
listen_addr: SocketAddr,
|
|
|
|
public_addr: Option<IpAddr>,
|
|
|
|
}
|
|
|
|
|
2020-12-12 20:14:15 +00:00
|
|
|
async fn net_handler_aux<M, F, R>(handler: Arc<F>, remote: NodeID, bytes: Bytes) -> Vec<u8>
|
2020-12-02 12:30:47 +00:00
|
|
|
where
|
|
|
|
M: Message + 'static,
|
2020-12-12 20:14:15 +00:00
|
|
|
F: Fn(NodeID, M) -> R + Send + Sync + 'static,
|
2020-12-02 17:10:07 +00:00
|
|
|
R: Future<Output = <M as Message>::Response> + Send + Sync,
|
2020-12-02 12:30:47 +00:00
|
|
|
{
|
|
|
|
debug!(
|
|
|
|
"Handling message of kind {:08x} from {}",
|
|
|
|
M::KIND,
|
|
|
|
hex::encode(remote)
|
|
|
|
);
|
2020-12-07 17:07:55 +00:00
|
|
|
let begin_time = Instant::now();
|
2020-12-02 12:30:47 +00:00
|
|
|
let res = match rmp_serde::decode::from_read_ref::<_, M>(&bytes[..]) {
|
2020-12-02 17:10:07 +00:00
|
|
|
Ok(msg) => Ok(handler(remote, msg).await),
|
|
|
|
Err(e) => Err(e.to_string()),
|
2020-12-02 12:30:47 +00:00
|
|
|
};
|
2020-12-07 17:07:55 +00:00
|
|
|
let end_time = Instant::now();
|
|
|
|
debug!(
|
|
|
|
"Request {:08x} from {} handled in {}msec",
|
|
|
|
M::KIND,
|
|
|
|
hex::encode(remote),
|
|
|
|
(end_time - begin_time).as_millis()
|
|
|
|
);
|
2021-10-12 11:18:24 +00:00
|
|
|
rmp_to_vec_all_named(&res).unwrap_or_default()
|
2020-12-02 12:30:47 +00:00
|
|
|
}
|
|
|
|
|
2020-12-12 20:14:15 +00:00
|
|
|
async fn local_handler_aux<M, F, R>(handler: Arc<F>, remote: NodeID, msg: DynMsg) -> DynMsg
|
2020-12-02 17:10:07 +00:00
|
|
|
where
|
|
|
|
M: Message + 'static,
|
2020-12-12 20:14:15 +00:00
|
|
|
F: Fn(NodeID, M) -> R + Send + Sync + 'static,
|
2020-12-02 17:10:07 +00:00
|
|
|
R: Future<Output = <M as Message>::Response> + Send + Sync,
|
|
|
|
{
|
2020-12-02 19:12:24 +00:00
|
|
|
debug!("Handling message of kind {:08x} from ourself", M::KIND);
|
2020-12-02 17:10:07 +00:00
|
|
|
let msg = (msg as Box<dyn Any + 'static>).downcast::<M>().unwrap();
|
|
|
|
let res = handler(remote, *msg).await;
|
|
|
|
Box::new(res)
|
|
|
|
}
|
|
|
|
|
2020-12-02 12:30:47 +00:00
|
|
|
impl NetApp {
|
2020-12-12 18:27:18 +00:00
|
|
|
/// Creates a new instance of NetApp, which can serve either as a full p2p node,
|
|
|
|
/// or just as a passive client. To upgrade to a full p2p node, spawn a listener
|
|
|
|
/// using `.listen()`
|
2020-12-12 20:14:15 +00:00
|
|
|
///
|
|
|
|
/// Our Peer ID is the public key associated to the secret key given here.
|
2020-12-12 18:27:18 +00:00
|
|
|
pub fn new(netid: auth::Key, privkey: ed25519::SecretKey) -> Arc<Self> {
|
2020-12-12 20:14:15 +00:00
|
|
|
let id = privkey.public_key();
|
2020-12-02 12:30:47 +00:00
|
|
|
let netapp = Arc::new(Self {
|
2020-12-12 18:27:18 +00:00
|
|
|
listen_params: ArcSwapOption::new(None),
|
2020-12-02 12:30:47 +00:00
|
|
|
netid,
|
2020-12-12 20:14:15 +00:00
|
|
|
id,
|
2020-12-02 12:30:47 +00:00
|
|
|
privkey,
|
|
|
|
server_conns: RwLock::new(HashMap::new()),
|
|
|
|
client_conns: RwLock::new(HashMap::new()),
|
|
|
|
msg_handlers: ArcSwap::new(Arc::new(HashMap::new())),
|
2020-12-02 19:12:24 +00:00
|
|
|
on_connected_handler: ArcSwapOption::new(None),
|
|
|
|
on_disconnected_handler: ArcSwapOption::new(None),
|
2020-12-02 12:30:47 +00:00
|
|
|
});
|
|
|
|
|
|
|
|
let netapp2 = netapp.clone();
|
2020-12-12 20:14:15 +00:00
|
|
|
netapp.add_msg_handler::<HelloMessage, _, _>(move |from: NodeID, msg: HelloMessage| {
|
|
|
|
netapp2.handle_hello_message(from, msg);
|
2021-10-12 11:33:42 +00:00
|
|
|
async {}
|
2020-12-12 20:14:15 +00:00
|
|
|
});
|
2020-12-02 12:30:47 +00:00
|
|
|
|
|
|
|
netapp
|
|
|
|
}
|
|
|
|
|
2020-12-02 19:12:24 +00:00
|
|
|
/// Set the handler to be called when a new connection (incoming or outgoing) has
|
|
|
|
/// been successfully established. Do not set this if using a peering strategy,
|
|
|
|
/// as the peering strategy will need to set this itself.
|
|
|
|
pub fn on_connected<F>(&self, handler: F)
|
2020-12-07 12:35:24 +00:00
|
|
|
where
|
2020-12-12 20:14:15 +00:00
|
|
|
F: Fn(NodeID, SocketAddr, bool) + Sized + Send + Sync + 'static,
|
2020-12-07 12:35:24 +00:00
|
|
|
{
|
|
|
|
self.on_connected_handler
|
|
|
|
.store(Some(Arc::new(Box::new(handler))));
|
2020-12-02 19:12:24 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
/// Set the handler to be called when an existing connection (incoming or outgoing) has
|
|
|
|
/// been closed by either party. Do not set this if using a peering strategy,
|
|
|
|
/// as the peering strategy will need to set this itself.
|
|
|
|
pub fn on_disconnected<F>(&self, handler: F)
|
2020-12-07 12:35:24 +00:00
|
|
|
where
|
2020-12-12 20:14:15 +00:00
|
|
|
F: Fn(NodeID, bool) + Sized + Send + Sync + 'static,
|
2020-12-07 12:35:24 +00:00
|
|
|
{
|
|
|
|
self.on_disconnected_handler
|
|
|
|
.store(Some(Arc::new(Box::new(handler))));
|
2020-12-02 19:12:24 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
/// Add a handler for a certain message type. Note that only one handler
|
|
|
|
/// can be specified for each message type.
|
2020-12-14 10:41:25 +00:00
|
|
|
/// The handler is an asynchronous function, i.e. a function that returns
|
|
|
|
/// a future.
|
2020-12-02 12:30:47 +00:00
|
|
|
pub fn add_msg_handler<M, F, R>(&self, handler: F)
|
|
|
|
where
|
|
|
|
M: Message + 'static,
|
2020-12-12 20:14:15 +00:00
|
|
|
F: Fn(NodeID, M) -> R + Send + Sync + 'static,
|
2020-12-02 17:10:07 +00:00
|
|
|
R: Future<Output = <M as Message>::Response> + Send + Sync + 'static,
|
2020-12-02 12:30:47 +00:00
|
|
|
{
|
|
|
|
let handler = Arc::new(handler);
|
2020-12-02 17:10:07 +00:00
|
|
|
|
2020-12-02 19:12:24 +00:00
|
|
|
let handler2 = handler.clone();
|
2020-12-12 20:14:15 +00:00
|
|
|
let net_handler = Box::new(move |remote: NodeID, bytes: Bytes| {
|
2020-12-02 12:30:47 +00:00
|
|
|
let fun: Pin<Box<dyn Future<Output = Vec<u8>> + Sync + Send>> =
|
2020-12-02 19:12:24 +00:00
|
|
|
Box::pin(net_handler_aux(handler2.clone(), remote, bytes));
|
2020-12-02 17:10:07 +00:00
|
|
|
fun
|
|
|
|
});
|
|
|
|
|
2021-10-12 11:18:24 +00:00
|
|
|
let self_id = self.id;
|
2020-12-02 17:10:07 +00:00
|
|
|
let local_handler = Box::new(move |msg: DynMsg| {
|
|
|
|
let fun: Pin<Box<dyn Future<Output = DynMsg> + Sync + Send>> =
|
|
|
|
Box::pin(local_handler_aux(handler.clone(), self_id, msg));
|
2020-12-02 12:30:47 +00:00
|
|
|
fun
|
|
|
|
});
|
2020-12-02 17:10:07 +00:00
|
|
|
|
|
|
|
let funs = Arc::new(Handler {
|
|
|
|
net_handler,
|
|
|
|
local_handler,
|
|
|
|
});
|
|
|
|
|
2020-12-02 12:30:47 +00:00
|
|
|
let mut handlers = self.msg_handlers.load().as_ref().clone();
|
2020-12-02 17:10:07 +00:00
|
|
|
handlers.insert(M::KIND, funs);
|
2020-12-02 12:30:47 +00:00
|
|
|
self.msg_handlers.store(Arc::new(handlers));
|
|
|
|
}
|
|
|
|
|
2020-12-02 19:12:24 +00:00
|
|
|
/// Main listening process for our app. This future runs during the whole
|
|
|
|
/// run time of our application.
|
2020-12-12 18:27:18 +00:00
|
|
|
/// If this is not called, the NetApp instance remains a passive client.
|
|
|
|
pub async fn listen(self: Arc<Self>, listen_addr: SocketAddr, public_addr: Option<IpAddr>) {
|
|
|
|
let listen_params = ListenParams {
|
|
|
|
listen_addr,
|
|
|
|
public_addr,
|
|
|
|
};
|
|
|
|
self.listen_params.store(Some(Arc::new(listen_params)));
|
|
|
|
|
2021-10-12 11:07:34 +00:00
|
|
|
let listener = TcpListener::bind(listen_addr).await.unwrap();
|
2020-12-12 18:27:18 +00:00
|
|
|
info!("Listening on {}", listen_addr);
|
2020-12-02 12:30:47 +00:00
|
|
|
|
|
|
|
loop {
|
|
|
|
// The second item contains the IP and port of the new connection.
|
|
|
|
let (socket, _) = listener.accept().await.unwrap();
|
|
|
|
info!(
|
|
|
|
"Incoming connection from {}, negotiating handshake...",
|
2021-02-17 16:43:07 +00:00
|
|
|
match socket.peer_addr() {
|
|
|
|
Ok(x) => format!("{}", x),
|
|
|
|
Err(e) => format!("<invalid addr: {}>", e),
|
|
|
|
}
|
2020-12-02 12:30:47 +00:00
|
|
|
);
|
|
|
|
let self2 = self.clone();
|
|
|
|
tokio::spawn(async move {
|
|
|
|
ServerConn::run(self2, socket)
|
|
|
|
.await
|
|
|
|
.log_err("ServerConn::run");
|
|
|
|
});
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2020-12-02 19:12:24 +00:00
|
|
|
/// Attempt to connect to a peer, given by its ip:port and its public key.
|
|
|
|
/// The public key will be checked during the secret handshake process.
|
|
|
|
/// This function returns once the connection has been established and a
|
|
|
|
/// successfull handshake was made. At this point we can send messages to
|
|
|
|
/// the other node with `Netapp::request`
|
2020-12-12 20:14:15 +00:00
|
|
|
pub async fn try_connect(self: Arc<Self>, ip: SocketAddr, id: NodeID) -> Result<(), Error> {
|
2020-12-02 19:12:24 +00:00
|
|
|
// Don't connect to ourself, we don't care
|
|
|
|
// but pretend we did
|
2020-12-12 20:14:15 +00:00
|
|
|
if id == self.id {
|
2020-12-02 17:10:07 +00:00
|
|
|
tokio::spawn(async move {
|
2020-12-02 19:12:24 +00:00
|
|
|
if let Some(h) = self.on_connected_handler.load().as_ref() {
|
2020-12-12 20:14:15 +00:00
|
|
|
h(id, ip, false);
|
2020-12-02 17:10:07 +00:00
|
|
|
}
|
|
|
|
});
|
|
|
|
return Ok(());
|
|
|
|
}
|
|
|
|
|
|
|
|
// Don't connect if already connected
|
2020-12-12 20:14:15 +00:00
|
|
|
if self.client_conns.read().unwrap().contains_key(&id) {
|
2020-12-02 12:30:47 +00:00
|
|
|
return Ok(());
|
|
|
|
}
|
2020-12-02 17:10:07 +00:00
|
|
|
|
2020-12-02 12:30:47 +00:00
|
|
|
let socket = TcpStream::connect(ip).await?;
|
|
|
|
info!("Connected to {}, negotiating handshake...", ip);
|
2021-10-12 11:18:24 +00:00
|
|
|
ClientConn::init(self, socket, id).await?;
|
2020-12-02 12:30:47 +00:00
|
|
|
Ok(())
|
|
|
|
}
|
|
|
|
|
2020-12-02 19:12:24 +00:00
|
|
|
/// Close the outgoing connection we have to a node specified by its public key,
|
|
|
|
/// if such a connection is currently open.
|
2020-12-12 20:14:15 +00:00
|
|
|
pub fn disconnect(self: &Arc<Self>, id: &NodeID) {
|
|
|
|
// If id is ourself, we're not supposed to have a connection open
|
|
|
|
if *id != self.id {
|
|
|
|
let conn = self.client_conns.write().unwrap().remove(id);
|
2020-12-07 11:39:19 +00:00
|
|
|
if let Some(c) = conn {
|
2020-12-07 12:35:24 +00:00
|
|
|
debug!(
|
|
|
|
"Closing connection to {} ({})",
|
2020-12-12 20:14:15 +00:00
|
|
|
hex::encode(c.peer_id),
|
2020-12-07 12:35:24 +00:00
|
|
|
c.remote_addr
|
|
|
|
);
|
2020-12-07 11:39:19 +00:00
|
|
|
c.close();
|
|
|
|
} else {
|
|
|
|
return;
|
|
|
|
}
|
2020-12-02 17:10:07 +00:00
|
|
|
}
|
|
|
|
|
2020-12-07 11:39:19 +00:00
|
|
|
// call on_disconnected_handler immediately, since the connection
|
|
|
|
// was removed
|
2020-12-12 20:14:15 +00:00
|
|
|
// (if id == self.id, we pretend we disconnected)
|
|
|
|
let id = *id;
|
2020-12-07 11:39:19 +00:00
|
|
|
let self2 = self.clone();
|
|
|
|
tokio::spawn(async move {
|
|
|
|
if let Some(h) = self2.on_disconnected_handler.load().as_ref() {
|
2020-12-12 20:14:15 +00:00
|
|
|
h(id, false);
|
2020-12-07 11:39:19 +00:00
|
|
|
}
|
|
|
|
});
|
2020-12-02 12:30:47 +00:00
|
|
|
}
|
|
|
|
|
2020-12-02 19:12:24 +00:00
|
|
|
/// Close the incoming connection from a certain client to us,
|
|
|
|
/// if such a connection is currently open.
|
2020-12-12 20:14:15 +00:00
|
|
|
pub fn server_disconnect(self: &Arc<Self>, id: &NodeID) {
|
|
|
|
let conn = self.server_conns.read().unwrap().get(id).cloned();
|
2020-12-02 19:12:24 +00:00
|
|
|
if let Some(c) = conn {
|
2020-12-07 12:35:24 +00:00
|
|
|
debug!(
|
|
|
|
"Closing incoming connection from {} ({})",
|
2020-12-12 20:14:15 +00:00
|
|
|
hex::encode(c.peer_id),
|
2020-12-07 12:35:24 +00:00
|
|
|
c.remote_addr
|
|
|
|
);
|
2020-12-02 19:12:24 +00:00
|
|
|
c.close();
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// Called from conn.rs when an incoming connection is successfully established
|
|
|
|
// Registers the connection in our list of connections
|
|
|
|
// Do not yet call the on_connected handler, because we don't know if the remote
|
|
|
|
// has an actual IP address and port we can call them back on.
|
|
|
|
// We will know this when they send a Hello message, which is handled below.
|
2020-12-12 20:14:15 +00:00
|
|
|
pub(crate) fn connected_as_server(&self, id: NodeID, conn: Arc<ServerConn>) {
|
2020-12-02 17:10:07 +00:00
|
|
|
info!("Accepted connection from {}", hex::encode(id));
|
|
|
|
|
2020-12-07 17:07:55 +00:00
|
|
|
self.server_conns.write().unwrap().insert(id, conn);
|
2020-12-02 12:30:47 +00:00
|
|
|
}
|
|
|
|
|
2020-12-02 19:12:24 +00:00
|
|
|
// Handle hello message from a client. This message is used for them to tell us
|
|
|
|
// that they are listening on a certain port number on which we can call them back.
|
|
|
|
// At this point we know they are a full network member, and not just a client,
|
|
|
|
// and we call the on_connected handler so that the peering strategy knows
|
|
|
|
// we have a new potential peer
|
2020-12-12 20:14:15 +00:00
|
|
|
fn handle_hello_message(&self, id: NodeID, msg: HelloMessage) {
|
2020-12-02 19:12:24 +00:00
|
|
|
if let Some(h) = self.on_connected_handler.load().as_ref() {
|
2020-12-02 12:30:47 +00:00
|
|
|
if let Some(c) = self.server_conns.read().unwrap().get(&id) {
|
2021-10-12 11:18:24 +00:00
|
|
|
let remote_ip = msg.server_addr.unwrap_or_else(|| c.remote_addr.ip());
|
2020-12-11 14:53:59 +00:00
|
|
|
let remote_addr = SocketAddr::new(remote_ip, msg.server_port);
|
2020-12-02 12:30:47 +00:00
|
|
|
h(id, remote_addr, true);
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2020-12-02 19:12:24 +00:00
|
|
|
// Called from conn.rs when an incoming connection is closed.
|
|
|
|
// We deregister the connection from server_conns and call the
|
|
|
|
// handler registered by on_disconnected
|
2020-12-12 20:14:15 +00:00
|
|
|
pub(crate) fn disconnected_as_server(&self, id: &NodeID, conn: Arc<ServerConn>) {
|
2020-12-02 17:10:07 +00:00
|
|
|
info!("Connection from {} closed", hex::encode(id));
|
|
|
|
|
2020-12-02 12:30:47 +00:00
|
|
|
let mut conn_list = self.server_conns.write().unwrap();
|
|
|
|
if let Some(c) = conn_list.get(id) {
|
|
|
|
if Arc::ptr_eq(c, &conn) {
|
|
|
|
conn_list.remove(id);
|
2020-12-07 17:07:55 +00:00
|
|
|
drop(conn_list);
|
2020-12-02 12:30:47 +00:00
|
|
|
|
2020-12-07 17:07:55 +00:00
|
|
|
if let Some(h) = self.on_disconnected_handler.load().as_ref() {
|
2020-12-12 20:14:15 +00:00
|
|
|
h(conn.peer_id, true);
|
2020-12-07 17:07:55 +00:00
|
|
|
}
|
2020-12-02 12:30:47 +00:00
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2020-12-02 19:12:24 +00:00
|
|
|
// Called from conn.rs when an outgoinc connection is successfully established.
|
|
|
|
// The connection is registered in self.client_conns, and the
|
|
|
|
// on_connected handler is called.
|
|
|
|
//
|
|
|
|
// Since we are ourself listening, we send them a Hello message so that
|
|
|
|
// they know on which port to call us back. (TODO: don't do this if we are
|
|
|
|
// just a simple client and not a full p2p node)
|
2020-12-12 20:14:15 +00:00
|
|
|
pub(crate) fn connected_as_client(&self, id: NodeID, conn: Arc<ClientConn>) {
|
2020-12-02 17:10:07 +00:00
|
|
|
info!("Connection established to {}", hex::encode(id));
|
|
|
|
|
2020-12-02 12:30:47 +00:00
|
|
|
{
|
2020-12-07 17:07:55 +00:00
|
|
|
let old_c_opt = self.client_conns.write().unwrap().insert(id, conn.clone());
|
|
|
|
if let Some(old_c) = old_c_opt {
|
2020-12-02 12:30:47 +00:00
|
|
|
tokio::spawn(async move { old_c.close() });
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2020-12-02 19:12:24 +00:00
|
|
|
if let Some(h) = self.on_connected_handler.load().as_ref() {
|
2020-12-12 20:14:15 +00:00
|
|
|
h(conn.peer_id, conn.remote_addr, false);
|
2020-12-02 12:30:47 +00:00
|
|
|
}
|
|
|
|
|
2020-12-12 18:27:18 +00:00
|
|
|
if let Some(lp) = self.listen_params.load_full() {
|
|
|
|
let server_addr = lp.public_addr;
|
|
|
|
let server_port = lp.listen_addr.port();
|
|
|
|
tokio::spawn(async move {
|
|
|
|
conn.request(
|
|
|
|
HelloMessage {
|
|
|
|
server_addr,
|
|
|
|
server_port,
|
|
|
|
},
|
|
|
|
PRIO_NORMAL,
|
|
|
|
)
|
2020-12-02 12:30:47 +00:00
|
|
|
.await
|
|
|
|
.log_err("Sending hello message");
|
2020-12-12 18:27:18 +00:00
|
|
|
});
|
|
|
|
}
|
2020-12-02 12:30:47 +00:00
|
|
|
}
|
|
|
|
|
2020-12-02 19:12:24 +00:00
|
|
|
// Called from conn.rs when an outgoinc connection is closed.
|
|
|
|
// The connection is removed from conn_list, and the on_disconnected handler
|
|
|
|
// is called.
|
2020-12-12 20:14:15 +00:00
|
|
|
pub(crate) fn disconnected_as_client(&self, id: &NodeID, conn: Arc<ClientConn>) {
|
2020-12-02 17:10:07 +00:00
|
|
|
info!("Connection to {} closed", hex::encode(id));
|
2020-12-02 12:30:47 +00:00
|
|
|
let mut conn_list = self.client_conns.write().unwrap();
|
|
|
|
if let Some(c) = conn_list.get(id) {
|
|
|
|
if Arc::ptr_eq(c, &conn) {
|
|
|
|
conn_list.remove(id);
|
2020-12-07 17:07:55 +00:00
|
|
|
drop(conn_list);
|
2020-12-02 12:30:47 +00:00
|
|
|
|
2020-12-02 19:12:24 +00:00
|
|
|
if let Some(h) = self.on_disconnected_handler.load().as_ref() {
|
2020-12-12 20:14:15 +00:00
|
|
|
h(conn.peer_id, false);
|
2020-12-02 19:12:24 +00:00
|
|
|
}
|
2020-12-02 12:30:47 +00:00
|
|
|
}
|
|
|
|
}
|
2020-12-07 11:39:19 +00:00
|
|
|
// else case: happens if connection was removed in .disconnect()
|
|
|
|
// in which case on_disconnected_handler was already called
|
2020-12-02 12:30:47 +00:00
|
|
|
}
|
2020-12-02 17:10:07 +00:00
|
|
|
|
2020-12-02 19:12:24 +00:00
|
|
|
/// Send a message to a remote host to which a client connection is already
|
|
|
|
/// established, and await their response. The target is the id of the peer we
|
|
|
|
/// want to send the message to.
|
|
|
|
/// The priority is an `u8`, with lower numbers meaning highest priority.
|
2020-12-02 17:10:07 +00:00
|
|
|
pub async fn request<T>(
|
|
|
|
&self,
|
2020-12-12 20:14:15 +00:00
|
|
|
target: &NodeID,
|
2020-12-02 17:10:07 +00:00
|
|
|
rq: T,
|
|
|
|
prio: RequestPriority,
|
|
|
|
) -> Result<<T as Message>::Response, Error>
|
|
|
|
where
|
|
|
|
T: Message + 'static,
|
|
|
|
{
|
2020-12-12 20:14:15 +00:00
|
|
|
if *target == self.id {
|
2020-12-02 17:10:07 +00:00
|
|
|
let handler = self.msg_handlers.load().get(&T::KIND).cloned();
|
|
|
|
match handler {
|
|
|
|
None => Err(Error::Message(format!(
|
|
|
|
"No handler registered for message kind {:08x}",
|
|
|
|
T::KIND
|
|
|
|
))),
|
|
|
|
Some(h) => {
|
|
|
|
let local_handler = &h.local_handler;
|
|
|
|
let res = local_handler(Box::new(rq)).await;
|
|
|
|
let res_t = (res as Box<dyn Any + 'static>)
|
|
|
|
.downcast::<<T as Message>::Response>()
|
|
|
|
.unwrap();
|
|
|
|
Ok(*res_t)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
} else {
|
|
|
|
let conn = self.client_conns.read().unwrap().get(target).cloned();
|
|
|
|
match conn {
|
|
|
|
None => Err(Error::Message(format!(
|
|
|
|
"Not connected: {}",
|
|
|
|
hex::encode(target)
|
|
|
|
))),
|
|
|
|
Some(c) => c.request(rq, prio).await,
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
2020-12-02 12:30:47 +00:00
|
|
|
}
|