mirror of
https://github.com/fafhrd91/actix-net
synced 2025-08-28 00:15:52 +02:00
Compare commits
6 Commits
rt-v2.0.0
...
service-v2
Author | SHA1 | Date | |
---|---|---|---|
|
a77b70aed2 | ||
|
c918da906b | ||
|
b5399c5631 | ||
|
7f0eddd794 | ||
|
db3385e865 | ||
|
4a8693d000 |
@@ -17,7 +17,7 @@ quote = "1.0.3"
|
|||||||
syn = { version = "^1", features = ["full"] }
|
syn = { version = "^1", features = ["full"] }
|
||||||
|
|
||||||
[dev-dependencies]
|
[dev-dependencies]
|
||||||
actix-rt = "2.0.0-beta.3"
|
actix-rt = "2.0.0"
|
||||||
|
|
||||||
futures-util = { version = "0.3", default-features = false }
|
futures-util = { version = "0.3", default-features = false }
|
||||||
trybuild = "1"
|
trybuild = "1"
|
||||||
|
@@ -2,6 +2,4 @@
|
|||||||
|
|
||||||
> Tokio-based single-threaded async runtime for the Actix ecosystem.
|
> Tokio-based single-threaded async runtime for the Actix ecosystem.
|
||||||
|
|
||||||
See documentation for detailed explanations these components: [https://docs.rs/actix-rt][docs].
|
See crate documentation for more: https://docs.rs/actix-rt.
|
||||||
|
|
||||||
[docs]: https://docs.rs/actix-rt
|
|
||||||
|
@@ -2,8 +2,12 @@
|
|||||||
|
|
||||||
## Unreleased - 2021-xx-xx
|
## Unreleased - 2021-xx-xx
|
||||||
* Hidden `ServerBuilder::start` method has been removed. Use `ServerBuilder::run`. [#246]
|
* Hidden `ServerBuilder::start` method has been removed. Use `ServerBuilder::run`. [#246]
|
||||||
|
* Add retry for EINTR(`io::Interrupted`) in `Accept`'s poll loop. [#264]
|
||||||
|
* Add `ServerBuilder::worker_max_blocking_threads` for customize blocking thread pool. [#265]
|
||||||
|
|
||||||
[#246]: https://github.com/actix/actix-net/pull/246
|
[#246]: https://github.com/actix/actix-net/pull/246
|
||||||
|
[#264]: https://github.com/actix/actix-net/pull/264
|
||||||
|
[#265]: https://github.com/actix/actix-net/pull/265
|
||||||
|
|
||||||
|
|
||||||
## 2.0.0-beta.2 - 2021-01-03
|
## 2.0.0-beta.2 - 2021-01-03
|
||||||
|
@@ -25,7 +25,7 @@ default = []
|
|||||||
[dependencies]
|
[dependencies]
|
||||||
actix-codec = "0.4.0-beta.1"
|
actix-codec = "0.4.0-beta.1"
|
||||||
actix-rt = { version = "2.0.0", default-features = false }
|
actix-rt = { version = "2.0.0", default-features = false }
|
||||||
actix-service = "2.0.0-beta.3"
|
actix-service = "2.0.0-beta.4"
|
||||||
actix-utils = "3.0.0-beta.1"
|
actix-utils = "3.0.0-beta.1"
|
||||||
|
|
||||||
futures-core = { version = "0.3.7", default-features = false, features = ["alloc"] }
|
futures-core = { version = "0.3.7", default-features = false, features = ["alloc"] }
|
||||||
@@ -36,7 +36,7 @@ slab = "0.4"
|
|||||||
tokio = { version = "1", features = ["sync"] }
|
tokio = { version = "1", features = ["sync"] }
|
||||||
|
|
||||||
[dev-dependencies]
|
[dev-dependencies]
|
||||||
actix-rt = "2.0.0-beta.2"
|
actix-rt = "2.0.0"
|
||||||
bytes = "1"
|
bytes = "1"
|
||||||
env_logger = "0.8"
|
env_logger = "0.8"
|
||||||
futures-util = { version = "0.3.7", default-features = false, features = ["sink"] }
|
futures-util = { version = "0.3.7", default-features = false, features = ["sink"] }
|
||||||
|
@@ -161,9 +161,16 @@ impl Accept {
|
|||||||
let mut events = mio::Events::with_capacity(128);
|
let mut events = mio::Events::with_capacity(128);
|
||||||
|
|
||||||
loop {
|
loop {
|
||||||
self.poll
|
if let Err(e) = self.poll.poll(&mut events, None) {
|
||||||
.poll(&mut events, None)
|
match e.kind() {
|
||||||
.unwrap_or_else(|e| panic!("Poll error: {}", e));
|
std::io::ErrorKind::Interrupted => {
|
||||||
|
continue;
|
||||||
|
}
|
||||||
|
_ => {
|
||||||
|
panic!("Poll error: {}", e);
|
||||||
|
}
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
for event in events.iter() {
|
for event in events.iter() {
|
||||||
let token = event.token();
|
let token = event.token();
|
||||||
|
@@ -19,7 +19,7 @@ use crate::signals::{Signal, Signals};
|
|||||||
use crate::socket::{MioListener, StdSocketAddr, StdTcpListener, ToSocketAddrs};
|
use crate::socket::{MioListener, StdSocketAddr, StdTcpListener, ToSocketAddrs};
|
||||||
use crate::socket::{MioTcpListener, MioTcpSocket};
|
use crate::socket::{MioTcpListener, MioTcpSocket};
|
||||||
use crate::waker_queue::{WakerInterest, WakerQueue};
|
use crate::waker_queue::{WakerInterest, WakerQueue};
|
||||||
use crate::worker::{self, ServerWorker, WorkerAvailability, WorkerHandle};
|
use crate::worker::{self, ServerWorker, ServerWorkerConfig, WorkerAvailability, WorkerHandle};
|
||||||
use crate::{join_all, Token};
|
use crate::{join_all, Token};
|
||||||
|
|
||||||
/// Server builder
|
/// Server builder
|
||||||
@@ -32,11 +32,11 @@ pub struct ServerBuilder {
|
|||||||
sockets: Vec<(Token, String, MioListener)>,
|
sockets: Vec<(Token, String, MioListener)>,
|
||||||
accept: AcceptLoop,
|
accept: AcceptLoop,
|
||||||
exit: bool,
|
exit: bool,
|
||||||
shutdown_timeout: Duration,
|
|
||||||
no_signals: bool,
|
no_signals: bool,
|
||||||
cmd: UnboundedReceiver<ServerCommand>,
|
cmd: UnboundedReceiver<ServerCommand>,
|
||||||
server: Server,
|
server: Server,
|
||||||
notify: Vec<oneshot::Sender<()>>,
|
notify: Vec<oneshot::Sender<()>>,
|
||||||
|
worker_config: ServerWorkerConfig,
|
||||||
}
|
}
|
||||||
|
|
||||||
impl Default for ServerBuilder {
|
impl Default for ServerBuilder {
|
||||||
@@ -60,11 +60,11 @@ impl ServerBuilder {
|
|||||||
accept: AcceptLoop::new(server.clone()),
|
accept: AcceptLoop::new(server.clone()),
|
||||||
backlog: 2048,
|
backlog: 2048,
|
||||||
exit: false,
|
exit: false,
|
||||||
shutdown_timeout: Duration::from_secs(30),
|
|
||||||
no_signals: false,
|
no_signals: false,
|
||||||
cmd: rx,
|
cmd: rx,
|
||||||
notify: Vec::new(),
|
notify: Vec::new(),
|
||||||
server,
|
server,
|
||||||
|
worker_config: ServerWorkerConfig::default(),
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
@@ -78,6 +78,24 @@ impl ServerBuilder {
|
|||||||
self
|
self
|
||||||
}
|
}
|
||||||
|
|
||||||
|
/// Set max number of threads for each worker's blocking task thread pool.
|
||||||
|
///
|
||||||
|
/// One thread pool is set up **per worker**; not shared across workers.
|
||||||
|
///
|
||||||
|
/// # Examples:
|
||||||
|
/// ```
|
||||||
|
/// # use actix_server::ServerBuilder;
|
||||||
|
/// let builder = ServerBuilder::new()
|
||||||
|
/// .workers(4) // server has 4 worker thread.
|
||||||
|
/// .worker_max_blocking_threads(4); // every worker has 4 max blocking threads.
|
||||||
|
/// ```
|
||||||
|
///
|
||||||
|
/// See [tokio::runtime::Builder::max_blocking_threads] for behavior reference.
|
||||||
|
pub fn worker_max_blocking_threads(mut self, num: usize) -> Self {
|
||||||
|
self.worker_config.max_blocking_threads(num);
|
||||||
|
self
|
||||||
|
}
|
||||||
|
|
||||||
/// Set the maximum number of pending connections.
|
/// Set the maximum number of pending connections.
|
||||||
///
|
///
|
||||||
/// This refers to the number of clients that can be waiting to be served.
|
/// This refers to the number of clients that can be waiting to be served.
|
||||||
@@ -124,7 +142,8 @@ impl ServerBuilder {
|
|||||||
///
|
///
|
||||||
/// By default shutdown timeout sets to 30 seconds.
|
/// By default shutdown timeout sets to 30 seconds.
|
||||||
pub fn shutdown_timeout(mut self, sec: u64) -> Self {
|
pub fn shutdown_timeout(mut self, sec: u64) -> Self {
|
||||||
self.shutdown_timeout = Duration::from_secs(sec);
|
self.worker_config
|
||||||
|
.shutdown_timeout(Duration::from_secs(sec));
|
||||||
self
|
self
|
||||||
}
|
}
|
||||||
|
|
||||||
@@ -297,7 +316,7 @@ impl ServerBuilder {
|
|||||||
let avail = WorkerAvailability::new(waker);
|
let avail = WorkerAvailability::new(waker);
|
||||||
let services = self.services.iter().map(|v| v.clone_factory()).collect();
|
let services = self.services.iter().map(|v| v.clone_factory()).collect();
|
||||||
|
|
||||||
ServerWorker::start(idx, services, avail, self.shutdown_timeout)
|
ServerWorker::start(idx, services, avail, self.worker_config)
|
||||||
}
|
}
|
||||||
|
|
||||||
fn handle_cmd(&mut self, item: ServerCommand) {
|
fn handle_cmd(&mut self, item: ServerCommand) {
|
||||||
|
@@ -133,7 +133,7 @@ pub(crate) struct ServerWorker {
|
|||||||
conns: Counter,
|
conns: Counter,
|
||||||
factories: Vec<Box<dyn InternalServiceFactory>>,
|
factories: Vec<Box<dyn InternalServiceFactory>>,
|
||||||
state: WorkerState,
|
state: WorkerState,
|
||||||
shutdown_timeout: Duration,
|
config: ServerWorkerConfig,
|
||||||
}
|
}
|
||||||
|
|
||||||
struct WorkerService {
|
struct WorkerService {
|
||||||
@@ -159,26 +159,62 @@ enum WorkerServiceStatus {
|
|||||||
Stopped,
|
Stopped,
|
||||||
}
|
}
|
||||||
|
|
||||||
|
/// Config for worker behavior passed down from server builder.
|
||||||
|
#[derive(Copy, Clone)]
|
||||||
|
pub(crate) struct ServerWorkerConfig {
|
||||||
|
shutdown_timeout: Duration,
|
||||||
|
max_blocking_threads: usize,
|
||||||
|
}
|
||||||
|
|
||||||
|
impl Default for ServerWorkerConfig {
|
||||||
|
fn default() -> Self {
|
||||||
|
// 512 is the default max blocking thread count of tokio runtime.
|
||||||
|
let max_blocking_threads = std::cmp::max(512 / num_cpus::get(), 1);
|
||||||
|
Self {
|
||||||
|
shutdown_timeout: Duration::from_secs(30),
|
||||||
|
max_blocking_threads,
|
||||||
|
}
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
|
impl ServerWorkerConfig {
|
||||||
|
pub(crate) fn max_blocking_threads(&mut self, num: usize) {
|
||||||
|
self.max_blocking_threads = num;
|
||||||
|
}
|
||||||
|
|
||||||
|
pub(crate) fn shutdown_timeout(&mut self, dur: Duration) {
|
||||||
|
self.shutdown_timeout = dur;
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
impl ServerWorker {
|
impl ServerWorker {
|
||||||
pub(crate) fn start(
|
pub(crate) fn start(
|
||||||
idx: usize,
|
idx: usize,
|
||||||
factories: Vec<Box<dyn InternalServiceFactory>>,
|
factories: Vec<Box<dyn InternalServiceFactory>>,
|
||||||
availability: WorkerAvailability,
|
availability: WorkerAvailability,
|
||||||
shutdown_timeout: Duration,
|
config: ServerWorkerConfig,
|
||||||
) -> WorkerHandle {
|
) -> WorkerHandle {
|
||||||
let (tx1, rx) = unbounded_channel();
|
let (tx1, rx) = unbounded_channel();
|
||||||
let (tx2, rx2) = unbounded_channel();
|
let (tx2, rx2) = unbounded_channel();
|
||||||
let avail = availability.clone();
|
let avail = availability.clone();
|
||||||
|
|
||||||
// every worker runs in it's own arbiter.
|
// every worker runs in it's own arbiter.
|
||||||
Arbiter::new().spawn(Box::pin(async move {
|
// use a custom tokio runtime builder to change the settings of runtime.
|
||||||
|
Arbiter::with_tokio_rt(move || {
|
||||||
|
tokio::runtime::Builder::new_current_thread()
|
||||||
|
.enable_all()
|
||||||
|
.max_blocking_threads(config.max_blocking_threads)
|
||||||
|
.build()
|
||||||
|
.unwrap()
|
||||||
|
})
|
||||||
|
.spawn(async move {
|
||||||
availability.set(false);
|
availability.set(false);
|
||||||
let mut wrk = MAX_CONNS_COUNTER.with(move |conns| ServerWorker {
|
let mut wrk = MAX_CONNS_COUNTER.with(move |conns| ServerWorker {
|
||||||
rx,
|
rx,
|
||||||
rx2,
|
rx2,
|
||||||
availability,
|
availability,
|
||||||
factories,
|
factories,
|
||||||
shutdown_timeout,
|
config,
|
||||||
services: Vec::new(),
|
services: Vec::new(),
|
||||||
conns: conns.clone(),
|
conns: conns.clone(),
|
||||||
state: WorkerState::Unavailable,
|
state: WorkerState::Unavailable,
|
||||||
@@ -198,6 +234,8 @@ impl ServerWorker {
|
|||||||
})
|
})
|
||||||
.collect::<Vec<_>>();
|
.collect::<Vec<_>>();
|
||||||
|
|
||||||
|
// a second spawn to make sure worker future runs as non boxed future.
|
||||||
|
// As Arbiter::spawn would box the future before send it to arbiter.
|
||||||
spawn(async move {
|
spawn(async move {
|
||||||
let res: Result<Vec<_>, _> = join_all(fut).await.into_iter().collect();
|
let res: Result<Vec<_>, _> = join_all(fut).await.into_iter().collect();
|
||||||
match res {
|
match res {
|
||||||
@@ -220,7 +258,7 @@ impl ServerWorker {
|
|||||||
}
|
}
|
||||||
wrk.await
|
wrk.await
|
||||||
});
|
});
|
||||||
}));
|
});
|
||||||
|
|
||||||
WorkerHandle::new(idx, tx1, tx2, avail)
|
WorkerHandle::new(idx, tx1, tx2, avail)
|
||||||
}
|
}
|
||||||
@@ -324,7 +362,7 @@ impl Future for ServerWorker {
|
|||||||
info!("Graceful worker shutdown, {} connections", num);
|
info!("Graceful worker shutdown, {} connections", num);
|
||||||
self.state = WorkerState::Shutdown(
|
self.state = WorkerState::Shutdown(
|
||||||
Box::pin(sleep_until(Instant::now() + Duration::from_secs(1))),
|
Box::pin(sleep_until(Instant::now() + Duration::from_secs(1))),
|
||||||
Box::pin(sleep_until(Instant::now() + self.shutdown_timeout)),
|
Box::pin(sleep_until(Instant::now() + self.config.shutdown_timeout)),
|
||||||
Some(result),
|
Some(result),
|
||||||
);
|
);
|
||||||
} else {
|
} else {
|
||||||
|
@@ -1,10 +1,13 @@
|
|||||||
# Changes
|
# Changes
|
||||||
|
|
||||||
## Unreleased - 2021-xx-xx
|
## Unreleased - 2021-xx-xx
|
||||||
* `Service::poll_ready` and `Service::call` take `&self`. [#247]
|
|
||||||
* `apply_fn` and `apply_fn_factory` would take `Fn(Req, &Service)` function type [#247]
|
|
||||||
* `apply_cfg` and `apply_cfg_factory` would take `Fn(Req, &Service)` function type [#247]
|
## 2.0.0-beta.4 - 2021-02-04
|
||||||
* `fn_service` module would take `Fn(Req)` function type. [#247]
|
* `Service::poll_ready` and `Service::call` receive `&self`. [#247]
|
||||||
|
* `apply_fn` and `apply_fn_factory` now receive `Fn(Req, &Service)` function type. [#247]
|
||||||
|
* `apply_cfg` and `apply_cfg_factory` now receive `Fn(Req, &Service)` function type. [#247]
|
||||||
|
* `fn_service` and friends now receive `Fn(Req)` function type. [#247]
|
||||||
|
|
||||||
[#247]: https://github.com/actix/actix-net/pull/247
|
[#247]: https://github.com/actix/actix-net/pull/247
|
||||||
|
|
||||||
|
@@ -1,9 +1,10 @@
|
|||||||
[package]
|
[package]
|
||||||
name = "actix-service"
|
name = "actix-service"
|
||||||
version = "2.0.0-beta.3"
|
version = "2.0.0-beta.4"
|
||||||
authors = [
|
authors = [
|
||||||
"Nikolay Kim <fafhrd91@gmail.com>",
|
"Nikolay Kim <fafhrd91@gmail.com>",
|
||||||
"Rob Ede <robjtede@icloud.com>",
|
"Rob Ede <robjtede@icloud.com>",
|
||||||
|
"fakeshadow <24548779@qq.com>",
|
||||||
]
|
]
|
||||||
description = "Service trait and combinators for representing asynchronous request/response operations."
|
description = "Service trait and combinators for representing asynchronous request/response operations."
|
||||||
keywords = ["network", "framework", "async", "futures", "service"]
|
keywords = ["network", "framework", "async", "futures", "service"]
|
||||||
|
@@ -2,6 +2,12 @@
|
|||||||
|
|
||||||
> Service trait and combinators for representing asynchronous request/response operations.
|
> Service trait and combinators for representing asynchronous request/response operations.
|
||||||
|
|
||||||
See documentation for detailed explanations these components: [https://docs.rs/actix-service][docs].
|
[](https://crates.io/crates/actix-service)
|
||||||
|
[](https://docs.rs/actix-service/2.0.0-beta.4)
|
||||||
|
[](https://blog.rust-lang.org/2020/03/12/Rust-1.46.html)
|
||||||
|

|
||||||
|
[](https://deps.rs/crate/actix-service/2.0.0-beta.4)
|
||||||
|
[](https://crates.io/crates/actix-service)
|
||||||
|
[](https://discord.gg/NWpN5mmg3x)
|
||||||
|
|
||||||
[docs]: https://docs.rs/actix-service
|
See documentation for detailed explanations of these components: https://docs.rs/actix-service.
|
||||||
|
@@ -31,10 +31,10 @@ connect = []
|
|||||||
openssl = ["tls-openssl", "tokio-openssl"]
|
openssl = ["tls-openssl", "tokio-openssl"]
|
||||||
|
|
||||||
# use rustls impls
|
# use rustls impls
|
||||||
rustls = ["tls-rustls", "webpki", "webpki-roots", "tokio-rustls"]
|
rustls = ["tokio-rustls", "webpki-roots"]
|
||||||
|
|
||||||
# use native-tls impls
|
# use native-tls impls
|
||||||
native-tls = ["tls-native-tls", "tokio-native-tls"]
|
native-tls = ["tokio-native-tls"]
|
||||||
|
|
||||||
# support http::Uri as connect address
|
# support http::Uri as connect address
|
||||||
uri = ["http"]
|
uri = ["http"]
|
||||||
@@ -42,28 +42,24 @@ uri = ["http"]
|
|||||||
[dependencies]
|
[dependencies]
|
||||||
actix-codec = "0.4.0-beta.1"
|
actix-codec = "0.4.0-beta.1"
|
||||||
actix-rt = { version = "2.0.0", default-features = false }
|
actix-rt = { version = "2.0.0", default-features = false }
|
||||||
actix-service = "2.0.0-beta.3"
|
actix-service = "2.0.0-beta.4"
|
||||||
actix-utils = "3.0.0-beta.1"
|
actix-utils = "3.0.0-beta.1"
|
||||||
|
|
||||||
derive_more = "0.99.5"
|
derive_more = "0.99.5"
|
||||||
futures-core = { version = "0.3.7", default-features = false, features = ["alloc"] }
|
futures-core = { version = "0.3.7", default-features = false, features = ["alloc"] }
|
||||||
http = { version = "0.2.3", optional = true }
|
http = { version = "0.2.3", optional = true }
|
||||||
log = "0.4"
|
log = "0.4"
|
||||||
|
tokio-util = { version = "0.6.3", default-features = false }
|
||||||
|
|
||||||
# openssl
|
# openssl
|
||||||
tls-openssl = { package = "openssl", version = "0.10", optional = true }
|
tls-openssl = { package = "openssl", version = "0.10", optional = true }
|
||||||
tokio-openssl = { version = "0.6", optional = true }
|
tokio-openssl = { version = "0.6", optional = true }
|
||||||
|
|
||||||
# TODO: Reduce dependencies where tokio wrappers re-export base crate.
|
|
||||||
|
|
||||||
# rustls
|
# rustls
|
||||||
tls-rustls = { package = "rustls", version = "0.19", optional = true }
|
|
||||||
tokio-rustls = { version = "0.22", optional = true }
|
tokio-rustls = { version = "0.22", optional = true }
|
||||||
webpki = { version = "0.21", optional = true }
|
|
||||||
webpki-roots = { version = "0.21", optional = true }
|
webpki-roots = { version = "0.21", optional = true }
|
||||||
|
|
||||||
# native-tls
|
# native-tls
|
||||||
tls-native-tls = { package = "native-tls", version = "0.2", optional = true }
|
|
||||||
tokio-native-tls = { version = "0.3", optional = true }
|
tokio-native-tls = { version = "0.3", optional = true }
|
||||||
|
|
||||||
[dev-dependencies]
|
[dev-dependencies]
|
||||||
|
@@ -15,9 +15,9 @@
|
|||||||
//! http --verify=false https://127.0.0.1:8443
|
//! http --verify=false https://127.0.0.1:8443
|
||||||
//! ```
|
//! ```
|
||||||
|
|
||||||
// this rename only exists because of how we have organised the crate's feature flags
|
// this use only exists because of how we have organised the crate
|
||||||
// it is not necessary for your actual code
|
// it is not necessary for your actual code
|
||||||
extern crate tls_rustls as rustls;
|
use tokio_rustls::rustls;
|
||||||
|
|
||||||
use std::{
|
use std::{
|
||||||
env,
|
env,
|
||||||
|
@@ -5,7 +5,7 @@ use actix_service::{Service, ServiceFactory};
|
|||||||
use actix_utils::counter::Counter;
|
use actix_utils::counter::Counter;
|
||||||
use futures_core::future::LocalBoxFuture;
|
use futures_core::future::LocalBoxFuture;
|
||||||
|
|
||||||
pub use native_tls::Error;
|
pub use tokio_native_tls::native_tls::Error;
|
||||||
pub use tokio_native_tls::{TlsAcceptor, TlsStream};
|
pub use tokio_native_tls::{TlsAcceptor, TlsStream};
|
||||||
|
|
||||||
use super::MAX_CONN_COUNTER;
|
use super::MAX_CONN_COUNTER;
|
||||||
|
@@ -12,7 +12,7 @@ use actix_utils::counter::{Counter, CounterGuard};
|
|||||||
use futures_core::future::LocalBoxFuture;
|
use futures_core::future::LocalBoxFuture;
|
||||||
use tokio_rustls::{Accept, TlsAcceptor};
|
use tokio_rustls::{Accept, TlsAcceptor};
|
||||||
|
|
||||||
pub use rustls::{ServerConfig, Session};
|
pub use tokio_rustls::rustls::{ServerConfig, Session};
|
||||||
pub use tokio_rustls::server::TlsStream;
|
pub use tokio_rustls::server::TlsStream;
|
||||||
|
|
||||||
use super::MAX_CONN_COUNTER;
|
use super::MAX_CONN_COUNTER;
|
||||||
|
@@ -11,6 +11,7 @@ use actix_rt::net::TcpStream;
|
|||||||
use actix_service::{Service, ServiceFactory};
|
use actix_service::{Service, ServiceFactory};
|
||||||
use futures_core::{future::LocalBoxFuture, ready};
|
use futures_core::{future::LocalBoxFuture, ready};
|
||||||
use log::{error, trace};
|
use log::{error, trace};
|
||||||
|
use tokio_util::sync::ReusableBoxFuture;
|
||||||
|
|
||||||
use super::connect::{Address, Connect, ConnectAddrs, Connection};
|
use super::connect::{Address, Connect, ConnectAddrs, Connection};
|
||||||
use super::error::ConnectError;
|
use super::error::ConnectError;
|
||||||
@@ -65,7 +66,7 @@ pub enum TcpConnectorResponse<T> {
|
|||||||
req: Option<T>,
|
req: Option<T>,
|
||||||
port: u16,
|
port: u16,
|
||||||
addrs: Option<VecDeque<SocketAddr>>,
|
addrs: Option<VecDeque<SocketAddr>>,
|
||||||
stream: Option<LocalBoxFuture<'static, Result<TcpStream, io::Error>>>,
|
stream: Option<ReusableBoxFuture<Result<TcpStream, io::Error>>>,
|
||||||
},
|
},
|
||||||
Error(Option<ConnectError>),
|
Error(Option<ConnectError>),
|
||||||
}
|
}
|
||||||
@@ -90,7 +91,7 @@ impl<T: Address> TcpConnectorResponse<T> {
|
|||||||
req: Some(req),
|
req: Some(req),
|
||||||
port,
|
port,
|
||||||
addrs: None,
|
addrs: None,
|
||||||
stream: Some(Box::pin(TcpStream::connect(addr))),
|
stream: Some(ReusableBoxFuture::new(TcpStream::connect(addr))),
|
||||||
},
|
},
|
||||||
|
|
||||||
// when resolver returns multiple socket addr for request they would be popped from
|
// when resolver returns multiple socket addr for request they would be popped from
|
||||||
@@ -119,7 +120,7 @@ impl<T: Address> Future for TcpConnectorResponse<T> {
|
|||||||
stream,
|
stream,
|
||||||
} => loop {
|
} => loop {
|
||||||
if let Some(new) = stream.as_mut() {
|
if let Some(new) = stream.as_mut() {
|
||||||
match ready!(new.as_mut().poll(cx)) {
|
match ready!(new.poll(cx)) {
|
||||||
Ok(sock) => {
|
Ok(sock) => {
|
||||||
let req = req.take().unwrap();
|
let req = req.take().unwrap();
|
||||||
trace!(
|
trace!(
|
||||||
@@ -146,7 +147,11 @@ impl<T: Address> Future for TcpConnectorResponse<T> {
|
|||||||
|
|
||||||
// try to connect
|
// try to connect
|
||||||
let addr = addrs.as_mut().unwrap().pop_front().unwrap();
|
let addr = addrs.as_mut().unwrap().pop_front().unwrap();
|
||||||
*stream = Some(Box::pin(TcpStream::connect(addr)));
|
|
||||||
|
match stream {
|
||||||
|
Some(rbf) => rbf.set(TcpStream::connect(addr)),
|
||||||
|
None => *stream = Some(ReusableBoxFuture::new(TcpStream::connect(addr))),
|
||||||
|
}
|
||||||
},
|
},
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
@@ -6,7 +6,7 @@ use std::{
|
|||||||
task::{Context, Poll},
|
task::{Context, Poll},
|
||||||
};
|
};
|
||||||
|
|
||||||
pub use rustls::Session;
|
pub use tokio_rustls::rustls::Session;
|
||||||
pub use tokio_rustls::{client::TlsStream, rustls::ClientConfig};
|
pub use tokio_rustls::{client::TlsStream, rustls::ClientConfig};
|
||||||
pub use webpki_roots::TLS_SERVER_ROOTS;
|
pub use webpki_roots::TLS_SERVER_ROOTS;
|
||||||
|
|
||||||
@@ -14,8 +14,8 @@ use actix_codec::{AsyncRead, AsyncWrite};
|
|||||||
use actix_service::{Service, ServiceFactory};
|
use actix_service::{Service, ServiceFactory};
|
||||||
use futures_core::{future::LocalBoxFuture, ready};
|
use futures_core::{future::LocalBoxFuture, ready};
|
||||||
use log::trace;
|
use log::trace;
|
||||||
|
use tokio_rustls::webpki::DNSNameRef;
|
||||||
use tokio_rustls::{Connect, TlsConnector};
|
use tokio_rustls::{Connect, TlsConnector};
|
||||||
use webpki::DNSNameRef;
|
|
||||||
|
|
||||||
use crate::connect::{Address, Connection};
|
use crate::connect::{Address, Connection};
|
||||||
|
|
||||||
|
@@ -4,12 +4,8 @@
|
|||||||
#![doc(html_logo_url = "https://actix.rs/img/logo.png")]
|
#![doc(html_logo_url = "https://actix.rs/img/logo.png")]
|
||||||
#![doc(html_favicon_url = "https://actix.rs/favicon.ico")]
|
#![doc(html_favicon_url = "https://actix.rs/favicon.ico")]
|
||||||
|
|
||||||
#[cfg(feature = "native-tls")]
|
|
||||||
extern crate tls_native_tls as native_tls;
|
|
||||||
#[cfg(feature = "openssl")]
|
#[cfg(feature = "openssl")]
|
||||||
extern crate tls_openssl as openssl;
|
extern crate tls_openssl as openssl;
|
||||||
#[cfg(feature = "rustls")]
|
|
||||||
extern crate tls_rustls as rustls;
|
|
||||||
|
|
||||||
#[cfg(feature = "accept")]
|
#[cfg(feature = "accept")]
|
||||||
pub mod accept;
|
pub mod accept;
|
||||||
|
@@ -16,7 +16,7 @@ name = "actix_tracing"
|
|||||||
path = "src/lib.rs"
|
path = "src/lib.rs"
|
||||||
|
|
||||||
[dependencies]
|
[dependencies]
|
||||||
actix-service = "2.0.0-beta.3"
|
actix-service = "2.0.0-beta.4"
|
||||||
|
|
||||||
futures-util = { version = "0.3.4", default-features = false }
|
futures-util = { version = "0.3.4", default-features = false }
|
||||||
tracing = "0.1"
|
tracing = "0.1"
|
||||||
|
@@ -18,7 +18,7 @@ path = "src/lib.rs"
|
|||||||
[dependencies]
|
[dependencies]
|
||||||
actix-codec = "0.4.0-beta.1"
|
actix-codec = "0.4.0-beta.1"
|
||||||
actix-rt = { version = "2.0.0", default-features = false }
|
actix-rt = { version = "2.0.0", default-features = false }
|
||||||
actix-service = "2.0.0-beta.3"
|
actix-service = "2.0.0-beta.4"
|
||||||
|
|
||||||
futures-core = { version = "0.3.7", default-features = false }
|
futures-core = { version = "0.3.7", default-features = false }
|
||||||
futures-sink = { version = "0.3.7", default-features = false }
|
futures-sink = { version = "0.3.7", default-features = false }
|
||||||
|
Reference in New Issue
Block a user