parent
9c970a8ceb
commit
a3e6ec98a0
@ -1,84 +1,271 @@ |
|||||||
|
use crate::actor::*; |
||||||
use crate::connection::*; |
use crate::connection::*; |
||||||
use crate::errors::*; |
use crate::errors::*; |
||||||
use crate::types::*; |
use crate::types::*; |
||||||
|
use crate::utils::spawn_and_log_error; |
||||||
use crate::utils::ResultSend; |
use crate::utils::ResultSend; |
||||||
|
use crate::{log, sleep}; |
||||||
|
use async_std::stream::StreamExt; |
||||||
|
use async_std::sync::{Arc, RwLock}; |
||||||
|
use futures::channel::mpsc; |
||||||
|
use futures::SinkExt; |
||||||
|
use once_cell::sync::Lazy; |
||||||
use p2p_repo::types::{PrivKey, PubKey}; |
use p2p_repo::types::{PrivKey, PubKey}; |
||||||
use p2p_repo::utils::generate_keypair; |
use p2p_repo::utils::generate_keypair; |
||||||
use std::collections::HashMap; |
use std::collections::HashMap; |
||||||
use std::net::IpAddr; |
use std::net::IpAddr; |
||||||
use std::sync::{Arc, RwLock}; |
|
||||||
|
|
||||||
use crate::actor::*; |
|
||||||
|
|
||||||
|
#[derive(Debug)] |
||||||
pub enum PeerConnection { |
pub enum PeerConnection { |
||||||
Core(IP), |
Core(IP), |
||||||
Client(Box<Arc<dyn IConnection>>), |
Client(ConnectionBase), |
||||||
NONE, |
NONE, |
||||||
} |
} |
||||||
|
|
||||||
|
#[derive(Debug)] |
||||||
pub struct BrokerPeerInfo { |
pub struct BrokerPeerInfo { |
||||||
lastPeerAdvert: Option<PeerAdvert>, //FIXME: remove Option
|
lastPeerAdvert: Option<PeerAdvert>, //FIXME: remove Option
|
||||||
connected: PeerConnection, |
connected: PeerConnection, |
||||||
} |
} |
||||||
|
|
||||||
|
#[derive(Debug)] |
||||||
pub struct DirectConnection { |
pub struct DirectConnection { |
||||||
ip: IP, |
ip: IP, |
||||||
interface: String, |
interface: String, |
||||||
remote_peer_id: DirectPeerId, |
remote_peer_id: DirectPeerId, |
||||||
tp: TransportProtocol, |
tp: TransportProtocol, |
||||||
//dir: ConnectionDir,
|
//dir: ConnectionDir,
|
||||||
cnx: Box<Arc<dyn IConnection>>, |
cnx: ConnectionBase, |
||||||
} |
} |
||||||
|
|
||||||
|
pub static BROKER: Lazy<Arc<RwLock<Broker>>> = Lazy::new(|| Arc::new(RwLock::new(Broker::new()))); |
||||||
|
|
||||||
pub struct Broker { |
pub struct Broker { |
||||||
//actors: Arc<RwLock<HashMap<i64, Box<dyn IActor>>>>,
|
//actors: Arc<RwLock<HashMap<i64, Box<dyn IActor>>>>,
|
||||||
direct_connections: Arc<RwLock<HashMap<IP, DirectConnection>>>, |
direct_connections: HashMap<IP, DirectConnection>, |
||||||
peers: Arc<RwLock<HashMap<DirectPeerId, BrokerPeerInfo>>>, |
peers: HashMap<DirectPeerId, BrokerPeerInfo>, |
||||||
|
shutdown: Option<Receiver<ProtocolError>>, |
||||||
|
shutdown_sender: Sender<ProtocolError>, |
||||||
|
closing: bool, |
||||||
} |
} |
||||||
|
|
||||||
impl Broker { |
impl Broker { |
||||||
|
pub fn reconnecting(&mut self, peer_id: &DirectPeerId) { |
||||||
|
let mut peerinfo = self.peers.get_mut(peer_id); |
||||||
|
match peerinfo { |
||||||
|
Some(info) => match &info.connected { |
||||||
|
PeerConnection::NONE => {} |
||||||
|
PeerConnection::Client(cb) => { |
||||||
|
info.connected = PeerConnection::NONE; |
||||||
|
} |
||||||
|
PeerConnection::Core(ip) => { |
||||||
|
self.direct_connections.remove(&ip); |
||||||
|
info.connected = PeerConnection::NONE; |
||||||
|
} |
||||||
|
}, |
||||||
|
None => {} |
||||||
|
} |
||||||
|
} |
||||||
|
pub fn remove(&mut self, peer_id: &DirectPeerId) { |
||||||
|
let removed = self.peers.remove(peer_id); |
||||||
|
match removed { |
||||||
|
Some(info) => match info.connected { |
||||||
|
PeerConnection::NONE => {} |
||||||
|
PeerConnection::Client(cb) => {} |
||||||
|
PeerConnection::Core(ip) => { |
||||||
|
self.direct_connections.remove(&ip); |
||||||
|
} |
||||||
|
}, |
||||||
|
None => {} |
||||||
|
} |
||||||
|
} |
||||||
|
|
||||||
pub fn new() -> Self { |
pub fn new() -> Self { |
||||||
|
let (shutdown_sender, shutdown_receiver) = mpsc::unbounded::<ProtocolError>(); |
||||||
Broker { |
Broker { |
||||||
direct_connections: Arc::new(RwLock::new(HashMap::new())), |
shutdown: Some(shutdown_receiver), |
||||||
peers: Arc::new(RwLock::new(HashMap::new())), |
shutdown_sender, |
||||||
|
direct_connections: HashMap::new(), |
||||||
|
peers: HashMap::new(), |
||||||
|
closing: false, |
||||||
|
} |
||||||
|
} |
||||||
|
|
||||||
|
fn take_shutdown(&mut self) -> Receiver<ProtocolError> { |
||||||
|
self.shutdown.take().unwrap() |
||||||
|
} |
||||||
|
|
||||||
|
pub async fn join_shutdown() -> Result<(), ProtocolError> { |
||||||
|
let mut shutdown_join: Receiver<ProtocolError>; |
||||||
|
{ |
||||||
|
shutdown_join = BROKER.write().await.take_shutdown(); |
||||||
|
} |
||||||
|
match shutdown_join.next().await { |
||||||
|
Some(ProtocolError::Closing) => Ok(()), |
||||||
|
Some(error) => Err(error), |
||||||
|
None => Ok(()), |
||||||
|
} |
||||||
|
} |
||||||
|
|
||||||
|
/// Used in tests mostly
|
||||||
|
pub async fn join_shutdown_with_timeout( |
||||||
|
timeout: std::time::Duration, |
||||||
|
) -> Result<(), ProtocolError> { |
||||||
|
async fn timer_shutdown(timeout: std::time::Duration) -> ResultSend<()> { |
||||||
|
async move { |
||||||
|
sleep!(timeout); |
||||||
|
log!("timeout for shutdown"); |
||||||
|
let _ = BROKER |
||||||
|
.write() |
||||||
|
.await |
||||||
|
.shutdown_sender |
||||||
|
.send(ProtocolError::Timeout) |
||||||
|
.await; |
||||||
|
} |
||||||
|
.await; |
||||||
|
Ok(()) |
||||||
|
} |
||||||
|
spawn_and_log_error(timer_shutdown(timeout)); |
||||||
|
Broker::join_shutdown().await |
||||||
|
} |
||||||
|
|
||||||
|
pub async fn graceful_shutdown() { |
||||||
|
let keys; |
||||||
|
{ |
||||||
|
let mut broker = BROKER.write().await; |
||||||
|
if broker.closing { |
||||||
|
return; |
||||||
|
} |
||||||
|
broker.closing = true; |
||||||
|
keys = Vec::from_iter(broker.peers.keys().cloned()); |
||||||
|
} |
||||||
|
for peer_id in keys { |
||||||
|
BROKER.write().await.close_peer_connection(&peer_id).await; |
||||||
} |
} |
||||||
|
let _ = BROKER |
||||||
|
.write() |
||||||
|
.await |
||||||
|
.shutdown_sender |
||||||
|
.send(ProtocolError::Closing) |
||||||
|
.await; |
||||||
|
} |
||||||
|
|
||||||
|
pub async fn shutdown(&mut self) { |
||||||
|
if self.closing { |
||||||
|
return; |
||||||
|
} |
||||||
|
self.closing = true; |
||||||
|
|
||||||
|
let _ = self.shutdown_sender.send(ProtocolError::Closing).await; |
||||||
} |
} |
||||||
|
|
||||||
pub async fn connect( |
pub async fn connect( |
||||||
&self, |
&mut self, |
||||||
cnx: Arc<dyn IConnection>, |
cnx: Box<dyn IConnection>, |
||||||
ip: IP, |
ip: IP, |
||||||
core: Option<String>, |
core: Option<String>, // the interface used as egress for this connection
|
||||||
peer_pubk: PrivKey, |
peer_pubk: PrivKey, |
||||||
peer_privk: PubKey, |
peer_privk: PubKey, |
||||||
remote_peer_id: DirectPeerId, |
remote_peer_id: DirectPeerId, |
||||||
) -> Result<(), NetError> { |
) -> Result<(), NetError> { |
||||||
|
if self.closing { |
||||||
|
return Err(NetError::Closing); |
||||||
|
} |
||||||
|
|
||||||
// TODO check that not already connected to peer
|
// TODO check that not already connected to peer
|
||||||
//IpAddr::from_str("127.0.0.1");
|
//IpAddr::from_str("127.0.0.1");
|
||||||
//cnx.open(url, peer_pubk, peer_privk).await?;
|
//cnx.open(url, peer_pubk, peer_privk).await?;
|
||||||
//let cnx = Arc::new();
|
//let cnx = Arc::new();
|
||||||
let (priv_key, pub_key) = generate_keypair(); |
let (priv_key, pub_key) = generate_keypair(); |
||||||
Arc::clone(&cnx) |
log!("CONNECTING"); |
||||||
.open(ip, priv_key, pub_key, remote_peer_id) |
let connection_res = cnx.open(ip, priv_key, pub_key, remote_peer_id).await; |
||||||
.await?; |
log!("CONNECTED {:?}", connection_res); |
||||||
|
let mut connection = connection_res.unwrap(); |
||||||
|
let join = connection.take_shutdown(); |
||||||
|
|
||||||
let connected = if core.is_some() { |
let connected = if core.is_some() { |
||||||
let dc = DirectConnection { |
let dc = DirectConnection { |
||||||
ip, |
ip, |
||||||
interface: core.unwrap(), |
interface: core.clone().unwrap(), |
||||||
remote_peer_id, |
remote_peer_id, |
||||||
tp: cnx.tp(), |
tp: connection.transport_protocol(), |
||||||
cnx: Box::new(Arc::clone(&cnx)), |
cnx: connection, |
||||||
}; |
}; |
||||||
self.direct_connections.write().unwrap().insert(ip, dc); |
self.direct_connections.insert(ip, dc); |
||||||
PeerConnection::Core(ip) |
PeerConnection::Core(ip) |
||||||
} else { |
} else { |
||||||
PeerConnection::Client(Box::new(Arc::clone(&cnx))) |
PeerConnection::Client(connection) |
||||||
}; |
}; |
||||||
let bpi = BrokerPeerInfo { |
let bpi = BrokerPeerInfo { |
||||||
lastPeerAdvert: None, |
lastPeerAdvert: None, |
||||||
connected, |
connected, |
||||||
}; |
}; |
||||||
self.peers.write().unwrap().insert(remote_peer_id, bpi); |
self.peers.insert(remote_peer_id, bpi); |
||||||
|
|
||||||
|
async fn watch_close( |
||||||
|
mut join: Receiver<NetError>, |
||||||
|
cnx: Box<dyn IConnection>, |
||||||
|
ip: IP, |
||||||
|
core: Option<String>, // the interface used as egress for this connection
|
||||||
|
peer_pubk: PrivKey, |
||||||
|
peer_privk: PubKey, |
||||||
|
remote_peer_id: DirectPeerId, |
||||||
|
) -> ResultSend<()> { |
||||||
|
async move { |
||||||
|
let res = join.next().await; |
||||||
|
log!("SOCKET IS CLOSED {:?} {:?}", res, &remote_peer_id); |
||||||
|
if res.is_some() { |
||||||
|
// we intend to reconnect
|
||||||
|
let mut broker = BROKER.write().await; |
||||||
|
broker.reconnecting(&remote_peer_id); |
||||||
|
// TODO: deal with cycle error https://users.rust-lang.org/t/recursive-async-method-causes-cycle-error/84628/5
|
||||||
|
// let result = broker
|
||||||
|
// .connect(cnx, ip, core, peer_pubk, peer_privk, remote_peer_id)
|
||||||
|
// .await;
|
||||||
|
// log!("SOCKET RECONNECTION {:?} {:?}", result, &remote_peer_id);
|
||||||
|
// TODO: deal with error and incremental backoff
|
||||||
|
} else { |
||||||
|
log!("REMOVED"); |
||||||
|
BROKER.write().await.remove(&remote_peer_id); |
||||||
|
} |
||||||
|
} |
||||||
|
.await; |
||||||
Ok(()) |
Ok(()) |
||||||
} |
} |
||||||
|
spawn_and_log_error(watch_close( |
||||||
|
join, |
||||||
|
cnx, |
||||||
|
ip, |
||||||
|
core, |
||||||
|
peer_pubk, |
||||||
|
peer_privk, |
||||||
|
remote_peer_id, |
||||||
|
)); |
||||||
|
Ok(()) |
||||||
|
} |
||||||
|
|
||||||
|
pub async fn close_peer_connection(&mut self, peer_id: &DirectPeerId) { |
||||||
|
if let Some(peer) = self.peers.get_mut(peer_id) { |
||||||
|
match &mut peer.connected { |
||||||
|
PeerConnection::Core(_) => { |
||||||
|
//TODO
|
||||||
|
unimplemented!(); |
||||||
|
} |
||||||
|
PeerConnection::Client(cb) => { |
||||||
|
cb.close().await; |
||||||
|
} |
||||||
|
PeerConnection::NONE => {} |
||||||
|
} |
||||||
|
//self.peers.remove(peer_id); // this is done in the watch_close instead
|
||||||
|
} |
||||||
|
} |
||||||
|
|
||||||
|
pub fn print_status(&self) { |
||||||
|
self.peers.iter().for_each(|(peerId, peerInfo)| { |
||||||
|
log!("PEER in BROKER {:?} {:?}", peerId, peerInfo); |
||||||
|
}); |
||||||
|
self.direct_connections.iter().for_each(|(ip, directCnx)| { |
||||||
|
log!("direct_connection in BROKER {:?} {:?}", ip, directCnx) |
||||||
|
}); |
||||||
|
} |
||||||
} |
} |
||||||
|
Loading…
Reference in new issue