2018-08-19 19:47:04 +02:00
|
|
|
use std::time::Duration;
|
2018-09-07 23:34:31 +02:00
|
|
|
use std::{io, mem, net};
|
2018-08-19 19:47:04 +02:00
|
|
|
|
|
|
|
use futures::sync::{mpsc, mpsc::unbounded};
|
|
|
|
use futures::{Future, Sink, Stream};
|
|
|
|
use net2::TcpBuilder;
|
|
|
|
use num_cpus;
|
|
|
|
|
|
|
|
use actix::{
|
2018-09-14 08:46:01 +02:00
|
|
|
actors::signal, fut, msgs::Execute, Actor, ActorFuture, Addr, Arbiter, AsyncContext,
|
|
|
|
Context, Handler, Response, StreamHandler, System, WrapFuture,
|
2018-08-19 19:47:04 +02:00
|
|
|
};
|
|
|
|
|
|
|
|
use super::accept::{AcceptLoop, AcceptNotify, Command};
|
2018-11-03 17:09:14 +01:00
|
|
|
use super::config::{ConfiguredService, ServiceConfig};
|
2018-09-27 05:40:45 +02:00
|
|
|
use super::services::{InternalServiceFactory, StreamNewService, StreamServiceFactory};
|
|
|
|
use super::services::{ServiceFactory, ServiceNewService};
|
2018-09-14 08:46:01 +02:00
|
|
|
use super::worker::{self, Worker, WorkerAvailability, WorkerClient};
|
2018-08-19 19:47:04 +02:00
|
|
|
use super::{PauseServer, ResumeServer, StopServer, Token};
|
|
|
|
|
|
|
|
pub(crate) enum ServerCommand {
|
|
|
|
WorkerDied(usize),
|
|
|
|
}
|
|
|
|
|
|
|
|
/// Server
|
2018-08-24 00:42:34 +02:00
|
|
|
pub struct Server {
|
2018-08-19 19:47:04 +02:00
|
|
|
threads: usize,
|
2018-11-03 17:09:14 +01:00
|
|
|
token: Token,
|
2018-09-14 08:46:01 +02:00
|
|
|
workers: Vec<(usize, WorkerClient)>,
|
2018-09-27 05:40:45 +02:00
|
|
|
services: Vec<Box<InternalServiceFactory>>,
|
2018-08-19 19:47:04 +02:00
|
|
|
sockets: Vec<(Token, net::TcpListener)>,
|
|
|
|
accept: AcceptLoop,
|
|
|
|
exit: bool,
|
2018-09-27 05:40:45 +02:00
|
|
|
shutdown_timeout: Duration,
|
2018-08-19 19:47:04 +02:00
|
|
|
signals: Option<Addr<signal::ProcessSignals>>,
|
|
|
|
no_signals: bool,
|
|
|
|
}
|
|
|
|
|
2018-08-24 00:42:34 +02:00
|
|
|
impl Default for Server {
|
2018-08-19 19:47:04 +02:00
|
|
|
fn default() -> Self {
|
2018-08-24 00:42:34 +02:00
|
|
|
Self::new()
|
2018-08-19 19:47:04 +02:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2018-08-24 00:42:34 +02:00
|
|
|
impl Server {
|
2018-08-19 19:47:04 +02:00
|
|
|
/// Create new Server instance
|
2018-08-24 00:42:34 +02:00
|
|
|
pub fn new() -> Server {
|
2018-08-19 19:47:04 +02:00
|
|
|
Server {
|
|
|
|
threads: num_cpus::get(),
|
2018-11-03 17:09:14 +01:00
|
|
|
token: Token(0),
|
2018-08-19 19:47:04 +02:00
|
|
|
workers: Vec::new(),
|
|
|
|
services: Vec::new(),
|
|
|
|
sockets: Vec::new(),
|
|
|
|
accept: AcceptLoop::new(),
|
|
|
|
exit: false,
|
2018-09-27 05:40:45 +02:00
|
|
|
shutdown_timeout: Duration::from_secs(30),
|
2018-08-19 19:47:04 +02:00
|
|
|
signals: None,
|
|
|
|
no_signals: false,
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
/// Set number of workers to start.
|
|
|
|
///
|
2018-08-22 06:11:16 +02:00
|
|
|
/// By default server uses number of available logical cpu as threads
|
2018-08-19 19:47:04 +02:00
|
|
|
/// count.
|
|
|
|
pub fn workers(mut self, num: usize) -> Self {
|
|
|
|
self.threads = num;
|
|
|
|
self
|
|
|
|
}
|
|
|
|
|
|
|
|
/// Sets the maximum per-worker number of concurrent connections.
|
|
|
|
///
|
|
|
|
/// All socket listeners will stop accepting connections when this limit is
|
|
|
|
/// reached for each worker.
|
|
|
|
///
|
2018-09-07 20:35:25 +02:00
|
|
|
/// By default max connections is set to a 25k per worker.
|
|
|
|
pub fn maxconn(self, num: usize) -> Self {
|
2018-09-08 18:36:38 +02:00
|
|
|
worker::max_concurrent_connections(num);
|
2018-08-19 19:47:04 +02:00
|
|
|
self
|
|
|
|
}
|
|
|
|
|
|
|
|
/// Stop actix system.
|
|
|
|
///
|
|
|
|
/// `SystemExit` message stops currently running system.
|
|
|
|
pub fn system_exit(mut self) -> Self {
|
|
|
|
self.exit = true;
|
|
|
|
self
|
|
|
|
}
|
|
|
|
|
|
|
|
#[doc(hidden)]
|
|
|
|
/// Set alternative address for `ProcessSignals` actor.
|
|
|
|
pub fn signals(mut self, addr: Addr<signal::ProcessSignals>) -> Self {
|
|
|
|
self.signals = Some(addr);
|
|
|
|
self
|
|
|
|
}
|
|
|
|
|
|
|
|
/// Disable signal handling
|
|
|
|
pub fn disable_signals(mut self) -> Self {
|
|
|
|
self.no_signals = true;
|
|
|
|
self
|
|
|
|
}
|
|
|
|
|
2018-09-27 05:40:45 +02:00
|
|
|
/// Timeout for graceful workers shutdown in seconds.
|
2018-08-19 19:47:04 +02:00
|
|
|
///
|
|
|
|
/// After receiving a stop signal, workers have this much time to finish
|
|
|
|
/// serving requests. Workers still alive after the timeout are force
|
|
|
|
/// dropped.
|
|
|
|
///
|
|
|
|
/// By default shutdown timeout sets to 30 seconds.
|
|
|
|
pub fn shutdown_timeout(mut self, sec: u16) -> Self {
|
2018-09-27 05:40:45 +02:00
|
|
|
self.shutdown_timeout = Duration::from_secs(u64::from(sec));
|
2018-08-19 19:47:04 +02:00
|
|
|
self
|
|
|
|
}
|
|
|
|
|
2018-08-22 20:36:56 +02:00
|
|
|
/// Run external configuration as part of the server building
|
|
|
|
/// process
|
|
|
|
///
|
|
|
|
/// This function is useful for moving parts of configuration to a
|
2018-11-03 17:09:14 +01:00
|
|
|
/// different module or even library.
|
|
|
|
pub fn configure<F>(mut self, f: F) -> io::Result<Server>
|
2018-08-22 20:36:56 +02:00
|
|
|
where
|
2018-11-03 17:09:14 +01:00
|
|
|
F: Fn(&mut ServiceConfig) -> io::Result<()>,
|
2018-08-22 20:36:56 +02:00
|
|
|
{
|
2018-11-03 17:09:14 +01:00
|
|
|
let mut cfg = ServiceConfig::new();
|
|
|
|
|
|
|
|
f(&mut cfg)?;
|
|
|
|
|
|
|
|
let mut srv = ConfiguredService::new(cfg.rt);
|
|
|
|
for (name, lst) in cfg.services {
|
|
|
|
let token = self.token.next();
|
|
|
|
srv.stream(token, name);
|
|
|
|
self.sockets.push((token, lst));
|
|
|
|
}
|
|
|
|
self.services.push(Box::new(srv));
|
|
|
|
|
|
|
|
Ok(self)
|
2018-08-22 20:36:56 +02:00
|
|
|
}
|
|
|
|
|
2018-08-19 19:47:04 +02:00
|
|
|
/// Add new service to server
|
2018-09-18 05:19:48 +02:00
|
|
|
pub fn bind<F, U, N: AsRef<str>>(mut self, name: N, addr: U, factory: F) -> io::Result<Self>
|
2018-08-19 19:47:04 +02:00
|
|
|
where
|
2018-09-27 05:40:45 +02:00
|
|
|
F: StreamServiceFactory,
|
2018-08-19 19:47:04 +02:00
|
|
|
U: net::ToSocketAddrs,
|
|
|
|
{
|
|
|
|
let sockets = bind_addr(addr)?;
|
|
|
|
|
2018-11-14 23:20:33 +01:00
|
|
|
let token = self.token.next();
|
|
|
|
self.services.push(StreamNewService::create(
|
|
|
|
name.as_ref().to_string(),
|
|
|
|
token,
|
|
|
|
factory,
|
|
|
|
));
|
|
|
|
|
2018-08-19 19:47:04 +02:00
|
|
|
for lst in sockets {
|
2018-11-14 23:20:33 +01:00
|
|
|
self.sockets.push((token, lst));
|
2018-08-19 19:47:04 +02:00
|
|
|
}
|
|
|
|
Ok(self)
|
|
|
|
}
|
|
|
|
|
|
|
|
/// Add new service to server
|
2018-09-18 05:19:48 +02:00
|
|
|
pub fn listen<F, N: AsRef<str>>(
|
2018-10-30 04:29:47 +01:00
|
|
|
mut self,
|
|
|
|
name: N,
|
|
|
|
lst: net::TcpListener,
|
|
|
|
factory: F,
|
2018-09-18 05:19:48 +02:00
|
|
|
) -> Self
|
2018-08-19 19:47:04 +02:00
|
|
|
where
|
2018-09-27 05:40:45 +02:00
|
|
|
F: StreamServiceFactory,
|
2018-08-19 19:47:04 +02:00
|
|
|
{
|
2018-11-03 17:09:14 +01:00
|
|
|
let token = self.token.next();
|
|
|
|
self.services.push(StreamNewService::create(
|
|
|
|
name.as_ref().to_string(),
|
|
|
|
token,
|
|
|
|
factory,
|
|
|
|
));
|
2018-09-27 05:40:45 +02:00
|
|
|
self.sockets.push((token, lst));
|
|
|
|
self
|
|
|
|
}
|
|
|
|
|
|
|
|
/// Add new service to server
|
|
|
|
pub fn listen2<F, N: AsRef<str>>(
|
2018-10-30 04:29:47 +01:00
|
|
|
mut self,
|
|
|
|
name: N,
|
|
|
|
lst: net::TcpListener,
|
|
|
|
factory: F,
|
2018-09-27 05:40:45 +02:00
|
|
|
) -> Self
|
|
|
|
where
|
|
|
|
F: ServiceFactory,
|
|
|
|
{
|
2018-11-03 17:09:14 +01:00
|
|
|
let token = self.token.next();
|
2018-09-27 05:40:45 +02:00
|
|
|
self.services.push(ServiceNewService::create(
|
|
|
|
name.as_ref().to_string(),
|
2018-11-03 17:09:14 +01:00
|
|
|
token,
|
2018-09-27 05:40:45 +02:00
|
|
|
factory,
|
|
|
|
));
|
2018-08-19 19:47:04 +02:00
|
|
|
self.sockets.push((token, lst));
|
|
|
|
self
|
|
|
|
}
|
|
|
|
|
|
|
|
/// Spawn new thread and start listening for incoming connections.
|
|
|
|
///
|
|
|
|
/// This method spawns new thread and starts new actix system. Other than
|
|
|
|
/// that it is similar to `start()` method. This method blocks.
|
|
|
|
///
|
|
|
|
/// This methods panics if no socket addresses get bound.
|
|
|
|
///
|
|
|
|
/// ```rust,ignore
|
|
|
|
/// # extern crate futures;
|
|
|
|
/// # extern crate actix_web;
|
|
|
|
/// # use futures::Future;
|
|
|
|
/// use actix_web::*;
|
|
|
|
///
|
|
|
|
/// fn main() {
|
|
|
|
/// Server::new().
|
|
|
|
/// .service(
|
|
|
|
/// HttpServer::new(|| App::new().resource("/", |r| r.h(|_| HttpResponse::Ok())))
|
|
|
|
/// .bind("127.0.0.1:0")
|
|
|
|
/// .expect("Can not bind to 127.0.0.1:0"))
|
|
|
|
/// .run();
|
|
|
|
/// }
|
|
|
|
/// ```
|
|
|
|
pub fn run(self) {
|
|
|
|
let sys = System::new("http-server");
|
|
|
|
self.start();
|
|
|
|
sys.run();
|
|
|
|
}
|
|
|
|
|
|
|
|
/// Starts Server Actor and returns its address
|
2018-08-24 00:42:34 +02:00
|
|
|
pub fn start(mut self) -> Addr<Server> {
|
2018-08-19 19:47:04 +02:00
|
|
|
if self.sockets.is_empty() {
|
|
|
|
panic!("Service should have at least one bound socket");
|
|
|
|
} else {
|
2018-09-18 05:19:48 +02:00
|
|
|
info!("Starting {} workers", self.threads);
|
2018-08-19 19:47:04 +02:00
|
|
|
|
|
|
|
// start workers
|
|
|
|
let mut workers = Vec::new();
|
|
|
|
for idx in 0..self.threads {
|
2018-09-14 08:46:01 +02:00
|
|
|
let worker = self.start_worker(idx, self.accept.get_notify());
|
|
|
|
workers.push(worker.clone());
|
|
|
|
self.workers.push((idx, worker));
|
2018-08-19 19:47:04 +02:00
|
|
|
}
|
|
|
|
|
|
|
|
// start accept thread
|
|
|
|
for sock in &self.sockets {
|
2018-09-18 05:19:48 +02:00
|
|
|
info!("Starting server on {}", sock.1.local_addr().ok().unwrap());
|
2018-08-19 19:47:04 +02:00
|
|
|
}
|
|
|
|
let rx = self
|
|
|
|
.accept
|
|
|
|
.start(mem::replace(&mut self.sockets, Vec::new()), workers);
|
|
|
|
|
|
|
|
// start http server actor
|
|
|
|
let signals = self.subscribe_to_signals();
|
|
|
|
let addr = Actor::create(move |ctx| {
|
|
|
|
ctx.add_stream(rx);
|
|
|
|
self
|
|
|
|
});
|
|
|
|
if let Some(signals) = signals {
|
|
|
|
signals.do_send(signal::Subscribe(addr.clone().recipient()))
|
|
|
|
}
|
|
|
|
addr
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
// subscribe to os signals
|
|
|
|
fn subscribe_to_signals(&self) -> Option<Addr<signal::ProcessSignals>> {
|
|
|
|
if !self.no_signals {
|
|
|
|
if let Some(ref signals) = self.signals {
|
|
|
|
Some(signals.clone())
|
|
|
|
} else {
|
|
|
|
Some(System::current().registry().get::<signal::ProcessSignals>())
|
|
|
|
}
|
|
|
|
} else {
|
|
|
|
None
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2018-09-14 08:46:01 +02:00
|
|
|
fn start_worker(&self, idx: usize, notify: AcceptNotify) -> WorkerClient {
|
2018-11-01 23:33:35 +01:00
|
|
|
let (tx1, rx1) = unbounded();
|
|
|
|
let (tx2, rx2) = unbounded();
|
2018-09-27 05:40:45 +02:00
|
|
|
let timeout = self.shutdown_timeout;
|
2018-09-07 22:06:51 +02:00
|
|
|
let avail = WorkerAvailability::new(notify);
|
2018-11-01 23:33:35 +01:00
|
|
|
let worker = WorkerClient::new(idx, tx1, tx2, avail.clone());
|
2018-09-27 05:40:45 +02:00
|
|
|
let services: Vec<Box<InternalServiceFactory>> =
|
2018-08-19 19:47:04 +02:00
|
|
|
self.services.iter().map(|v| v.clone_factory()).collect();
|
|
|
|
|
2018-09-27 05:40:45 +02:00
|
|
|
Arbiter::new(format!("actix-net-worker-{}", idx)).do_send(Execute::new(move || {
|
2018-11-01 23:33:35 +01:00
|
|
|
Worker::start(rx1, rx2, services, avail, timeout.clone());
|
2018-09-14 08:46:01 +02:00
|
|
|
Ok::<_, ()>(())
|
|
|
|
}));
|
2018-08-19 19:47:04 +02:00
|
|
|
|
2018-09-14 08:46:01 +02:00
|
|
|
worker
|
2018-08-19 19:47:04 +02:00
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2018-08-24 00:42:34 +02:00
|
|
|
impl Actor for Server {
|
2018-08-19 19:47:04 +02:00
|
|
|
type Context = Context<Self>;
|
|
|
|
}
|
|
|
|
|
|
|
|
/// Signals support
|
|
|
|
/// Handle `SIGINT`, `SIGTERM`, `SIGQUIT` signals and stop actix system
|
|
|
|
/// message to `System` actor.
|
2018-08-24 00:42:34 +02:00
|
|
|
impl Handler<signal::Signal> for Server {
|
2018-08-19 19:47:04 +02:00
|
|
|
type Result = ();
|
|
|
|
|
|
|
|
fn handle(&mut self, msg: signal::Signal, ctx: &mut Context<Self>) {
|
|
|
|
match msg.0 {
|
|
|
|
signal::SignalType::Int => {
|
|
|
|
info!("SIGINT received, exiting");
|
|
|
|
self.exit = true;
|
|
|
|
Handler::<StopServer>::handle(self, StopServer { graceful: false }, ctx);
|
|
|
|
}
|
|
|
|
signal::SignalType::Term => {
|
|
|
|
info!("SIGTERM received, stopping");
|
|
|
|
self.exit = true;
|
|
|
|
Handler::<StopServer>::handle(self, StopServer { graceful: true }, ctx);
|
|
|
|
}
|
|
|
|
signal::SignalType::Quit => {
|
|
|
|
info!("SIGQUIT received, exiting");
|
|
|
|
self.exit = true;
|
|
|
|
Handler::<StopServer>::handle(self, StopServer { graceful: false }, ctx);
|
|
|
|
}
|
|
|
|
_ => (),
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2018-08-24 00:42:34 +02:00
|
|
|
impl Handler<PauseServer> for Server {
|
2018-08-19 19:47:04 +02:00
|
|
|
type Result = ();
|
|
|
|
|
|
|
|
fn handle(&mut self, _: PauseServer, _: &mut Context<Self>) {
|
|
|
|
self.accept.send(Command::Pause);
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2018-08-24 00:42:34 +02:00
|
|
|
impl Handler<ResumeServer> for Server {
|
2018-08-19 19:47:04 +02:00
|
|
|
type Result = ();
|
|
|
|
|
|
|
|
fn handle(&mut self, _: ResumeServer, _: &mut Context<Self>) {
|
|
|
|
self.accept.send(Command::Resume);
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2018-08-24 00:42:34 +02:00
|
|
|
impl Handler<StopServer> for Server {
|
2018-08-19 19:47:04 +02:00
|
|
|
type Result = Response<(), ()>;
|
|
|
|
|
|
|
|
fn handle(&mut self, msg: StopServer, ctx: &mut Context<Self>) -> Self::Result {
|
|
|
|
// stop accept thread
|
|
|
|
self.accept.send(Command::Stop);
|
|
|
|
|
|
|
|
// stop workers
|
|
|
|
let (tx, rx) = mpsc::channel(1);
|
|
|
|
|
|
|
|
for worker in &self.workers {
|
|
|
|
let tx2 = tx.clone();
|
|
|
|
ctx.spawn(
|
|
|
|
worker
|
|
|
|
.1
|
2018-09-27 05:40:45 +02:00
|
|
|
.stop(msg.graceful)
|
2018-08-19 19:47:04 +02:00
|
|
|
.into_actor(self)
|
|
|
|
.then(move |_, slf, ctx| {
|
|
|
|
slf.workers.pop();
|
|
|
|
if slf.workers.is_empty() {
|
|
|
|
let _ = tx2.send(());
|
|
|
|
|
|
|
|
// we need to stop system if server was spawned
|
|
|
|
if slf.exit {
|
|
|
|
ctx.run_later(Duration::from_millis(300), |_, _| {
|
|
|
|
System::current().stop();
|
|
|
|
});
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
fut::ok(())
|
|
|
|
}),
|
|
|
|
);
|
|
|
|
}
|
|
|
|
|
|
|
|
if !self.workers.is_empty() {
|
|
|
|
Response::async(rx.into_future().map(|_| ()).map_err(|_| ()))
|
|
|
|
} else {
|
|
|
|
// we need to stop system if server was spawned
|
|
|
|
if self.exit {
|
|
|
|
ctx.run_later(Duration::from_millis(300), |_, _| {
|
|
|
|
System::current().stop();
|
|
|
|
});
|
|
|
|
}
|
|
|
|
Response::reply(Ok(()))
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
/// Commands from accept threads
|
2018-08-24 00:42:34 +02:00
|
|
|
impl StreamHandler<ServerCommand, ()> for Server {
|
2018-08-19 19:47:04 +02:00
|
|
|
fn finished(&mut self, _: &mut Context<Self>) {}
|
|
|
|
|
|
|
|
fn handle(&mut self, msg: ServerCommand, _: &mut Context<Self>) {
|
|
|
|
match msg {
|
|
|
|
ServerCommand::WorkerDied(idx) => {
|
|
|
|
let mut found = false;
|
|
|
|
for i in 0..self.workers.len() {
|
|
|
|
if self.workers[i].0 == idx {
|
|
|
|
self.workers.swap_remove(i);
|
|
|
|
found = true;
|
|
|
|
break;
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
if found {
|
|
|
|
error!("Worker has died {:?}, restarting", idx);
|
|
|
|
|
|
|
|
let mut new_idx = self.workers.len();
|
|
|
|
'found: loop {
|
|
|
|
for i in 0..self.workers.len() {
|
|
|
|
if self.workers[i].0 == new_idx {
|
|
|
|
new_idx += 1;
|
|
|
|
continue 'found;
|
|
|
|
}
|
|
|
|
}
|
|
|
|
break;
|
|
|
|
}
|
|
|
|
|
2018-09-14 08:46:01 +02:00
|
|
|
let worker = self.start_worker(new_idx, self.accept.get_notify());
|
|
|
|
self.workers.push((new_idx, worker.clone()));
|
2018-08-19 19:47:04 +02:00
|
|
|
self.accept.send(Command::Worker(worker));
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2018-11-03 17:09:14 +01:00
|
|
|
pub(super) fn bind_addr<S: net::ToSocketAddrs>(addr: S) -> io::Result<Vec<net::TcpListener>> {
|
2018-08-19 19:47:04 +02:00
|
|
|
let mut err = None;
|
|
|
|
let mut succ = false;
|
|
|
|
let mut sockets = Vec::new();
|
|
|
|
for addr in addr.to_socket_addrs()? {
|
|
|
|
match create_tcp_listener(addr) {
|
|
|
|
Ok(lst) => {
|
|
|
|
succ = true;
|
|
|
|
sockets.push(lst);
|
|
|
|
}
|
|
|
|
Err(e) => err = Some(e),
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
if !succ {
|
|
|
|
if let Some(e) = err.take() {
|
|
|
|
Err(e)
|
|
|
|
} else {
|
|
|
|
Err(io::Error::new(
|
|
|
|
io::ErrorKind::Other,
|
|
|
|
"Can not bind to address.",
|
|
|
|
))
|
|
|
|
}
|
|
|
|
} else {
|
|
|
|
Ok(sockets)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
|
|
|
fn create_tcp_listener(addr: net::SocketAddr) -> io::Result<net::TcpListener> {
|
|
|
|
let builder = match addr {
|
|
|
|
net::SocketAddr::V4(_) => TcpBuilder::new_v4()?,
|
|
|
|
net::SocketAddr::V6(_) => TcpBuilder::new_v6()?,
|
|
|
|
};
|
|
|
|
builder.reuse_address(true)?;
|
|
|
|
builder.bind(addr)?;
|
|
|
|
Ok(builder.listen(1024)?)
|
|
|
|
}
|