mirror of
https://github.com/ntex-rs/ntex.git
synced 2025-04-05 05:47:40 +03:00
drop direct tokio dependency
This commit is contained in:
parent
fa59cd2d1c
commit
5f2f65e403
6 changed files with 66 additions and 57 deletions
|
@ -1,5 +1,9 @@
|
||||||
# Changes
|
# Changes
|
||||||
|
|
||||||
|
## [0.3.19] - 2021-07-xx
|
||||||
|
|
||||||
|
* drop direct tokio dependency
|
||||||
|
|
||||||
## [0.3.18] - 2021-06-03
|
## [0.3.18] - 2021-06-03
|
||||||
|
|
||||||
* server: expose server status change notifications
|
* server: expose server status change notifications
|
||||||
|
|
|
@ -1,6 +1,6 @@
|
||||||
[package]
|
[package]
|
||||||
name = "ntex"
|
name = "ntex"
|
||||||
version = "0.3.18"
|
version = "0.3.19"
|
||||||
authors = ["ntex contributors <team@ntex.rs>"]
|
authors = ["ntex contributors <team@ntex.rs>"]
|
||||||
description = "Framework for composable network services"
|
description = "Framework for composable network services"
|
||||||
readme = "README.md"
|
readme = "README.md"
|
||||||
|
@ -68,7 +68,9 @@ sha-1 = "0.9"
|
||||||
slab = "0.4"
|
slab = "0.4"
|
||||||
serde = { version = "1.0", features=["derive"] }
|
serde = { version = "1.0", features=["derive"] }
|
||||||
socket2 = "0.4"
|
socket2 = "0.4"
|
||||||
tokio = { version = "1", default-features = false, features = ["sync"] }
|
|
||||||
|
async-oneshot = "0.5.0"
|
||||||
|
async-channel = "1.6.1"
|
||||||
|
|
||||||
# http/web framework
|
# http/web framework
|
||||||
h2 = { version = "0.3", optional = true }
|
h2 = { version = "0.3", optional = true }
|
||||||
|
|
|
@ -1,10 +1,11 @@
|
||||||
use std::task::{Context, Poll};
|
use std::task::{Context, Poll};
|
||||||
use std::{future::Future, io, mem, net, pin::Pin, time::Duration};
|
use std::{future::Future, io, mem, net, pin::Pin, time::Duration};
|
||||||
|
|
||||||
|
use async_channel::{unbounded, Receiver};
|
||||||
|
use async_oneshot as oneshot;
|
||||||
|
use futures_core::Stream;
|
||||||
use log::{error, info};
|
use log::{error, info};
|
||||||
use socket2::{Domain, SockAddr, Socket, Type};
|
use socket2::{Domain, SockAddr, Socket, Type};
|
||||||
use tokio::sync::mpsc::{unbounded_channel, UnboundedReceiver};
|
|
||||||
use tokio::sync::oneshot;
|
|
||||||
|
|
||||||
use crate::rt::{net::TcpStream, spawn, time::sleep, System};
|
use crate::rt::{net::TcpStream, spawn, time::sleep, System};
|
||||||
use crate::util::join_all;
|
use crate::util::join_all;
|
||||||
|
@ -31,7 +32,7 @@ pub struct ServerBuilder {
|
||||||
exit: bool,
|
exit: bool,
|
||||||
shutdown_timeout: Duration,
|
shutdown_timeout: Duration,
|
||||||
no_signals: bool,
|
no_signals: bool,
|
||||||
cmd: UnboundedReceiver<ServerCommand>,
|
cmd: Receiver<ServerCommand>,
|
||||||
server: Server,
|
server: Server,
|
||||||
notify: Vec<oneshot::Sender<()>>,
|
notify: Vec<oneshot::Sender<()>>,
|
||||||
}
|
}
|
||||||
|
@ -45,7 +46,7 @@ impl Default for ServerBuilder {
|
||||||
impl ServerBuilder {
|
impl ServerBuilder {
|
||||||
/// Create new Server builder instance
|
/// Create new Server builder instance
|
||||||
pub fn new() -> ServerBuilder {
|
pub fn new() -> ServerBuilder {
|
||||||
let (tx, rx) = unbounded_channel();
|
let (tx, rx) = unbounded();
|
||||||
let server = Server::new(tx);
|
let server = Server::new(tx);
|
||||||
|
|
||||||
ServerBuilder {
|
ServerBuilder {
|
||||||
|
@ -323,11 +324,11 @@ impl ServerBuilder {
|
||||||
|
|
||||||
fn handle_cmd(&mut self, item: ServerCommand) {
|
fn handle_cmd(&mut self, item: ServerCommand) {
|
||||||
match item {
|
match item {
|
||||||
ServerCommand::Pause(tx) => {
|
ServerCommand::Pause(mut tx) => {
|
||||||
self.accept.send(Command::Pause);
|
self.accept.send(Command::Pause);
|
||||||
let _ = tx.send(());
|
let _ = tx.send(());
|
||||||
}
|
}
|
||||||
ServerCommand::Resume(tx) => {
|
ServerCommand::Resume(mut tx) => {
|
||||||
self.accept.send(Command::Resume);
|
self.accept.send(Command::Resume);
|
||||||
let _ = tx.send(());
|
let _ = tx.send(());
|
||||||
}
|
}
|
||||||
|
@ -386,10 +387,10 @@ impl ServerBuilder {
|
||||||
spawn(async move {
|
spawn(async move {
|
||||||
let _ = join_all(futs).await;
|
let _ = join_all(futs).await;
|
||||||
|
|
||||||
if let Some(tx) = completion {
|
if let Some(mut tx) = completion {
|
||||||
let _ = tx.send(());
|
let _ = tx.send(());
|
||||||
}
|
}
|
||||||
for tx in notify {
|
for mut tx in notify {
|
||||||
let _ = tx.send(());
|
let _ = tx.send(());
|
||||||
}
|
}
|
||||||
if exit {
|
if exit {
|
||||||
|
@ -405,10 +406,10 @@ impl ServerBuilder {
|
||||||
System::current().stop();
|
System::current().stop();
|
||||||
});
|
});
|
||||||
}
|
}
|
||||||
if let Some(tx) = completion {
|
if let Some(mut tx) = completion {
|
||||||
let _ = tx.send(());
|
let _ = tx.send(());
|
||||||
}
|
}
|
||||||
for tx in notify {
|
for mut tx in notify {
|
||||||
let _ = tx.send(());
|
let _ = tx.send(());
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
@ -451,7 +452,7 @@ impl Future for ServerBuilder {
|
||||||
|
|
||||||
fn poll(mut self: Pin<&mut Self>, cx: &mut Context<'_>) -> Poll<Self::Output> {
|
fn poll(mut self: Pin<&mut Self>, cx: &mut Context<'_>) -> Poll<Self::Output> {
|
||||||
loop {
|
loop {
|
||||||
match Pin::new(&mut self.cmd).poll_recv(cx) {
|
match Pin::new(&mut self.cmd).poll_next(cx) {
|
||||||
Poll::Ready(Some(it)) => self.as_mut().get_mut().handle_cmd(it),
|
Poll::Ready(Some(it)) => self.as_mut().get_mut().handle_cmd(it),
|
||||||
Poll::Ready(None) => return Poll::Pending,
|
Poll::Ready(None) => return Poll::Pending,
|
||||||
Poll::Pending => return Poll::Pending,
|
Poll::Pending => return Poll::Pending,
|
||||||
|
|
|
@ -4,8 +4,8 @@ use std::sync::atomic::{AtomicUsize, Ordering};
|
||||||
use std::task::{Context, Poll};
|
use std::task::{Context, Poll};
|
||||||
use std::{future::Future, io, pin::Pin};
|
use std::{future::Future, io, pin::Pin};
|
||||||
|
|
||||||
use tokio::sync::mpsc::UnboundedSender;
|
use async_channel::Sender;
|
||||||
use tokio::sync::oneshot;
|
use async_oneshot as oneshot;
|
||||||
|
|
||||||
use crate::util::counter::Counter;
|
use crate::util::counter::Counter;
|
||||||
|
|
||||||
|
@ -98,13 +98,10 @@ enum ServerCommand {
|
||||||
|
|
||||||
/// Server controller
|
/// Server controller
|
||||||
#[derive(Debug)]
|
#[derive(Debug)]
|
||||||
pub struct Server(
|
pub struct Server(Sender<ServerCommand>, Option<oneshot::Receiver<()>>);
|
||||||
UnboundedSender<ServerCommand>,
|
|
||||||
Option<oneshot::Receiver<()>>,
|
|
||||||
);
|
|
||||||
|
|
||||||
impl Server {
|
impl Server {
|
||||||
fn new(tx: UnboundedSender<ServerCommand>) -> Self {
|
fn new(tx: Sender<ServerCommand>) -> Self {
|
||||||
Server(tx, None)
|
Server(tx, None)
|
||||||
}
|
}
|
||||||
|
|
||||||
|
@ -114,11 +111,11 @@ impl Server {
|
||||||
}
|
}
|
||||||
|
|
||||||
fn signal(&self, sig: signals::Signal) {
|
fn signal(&self, sig: signals::Signal) {
|
||||||
let _ = self.0.send(ServerCommand::Signal(sig));
|
let _ = self.0.try_send(ServerCommand::Signal(sig));
|
||||||
}
|
}
|
||||||
|
|
||||||
fn worker_faulted(&self, idx: usize) {
|
fn worker_faulted(&self, idx: usize) {
|
||||||
let _ = self.0.send(ServerCommand::WorkerFaulted(idx));
|
let _ = self.0.try_send(ServerCommand::WorkerFaulted(idx));
|
||||||
}
|
}
|
||||||
|
|
||||||
/// Pause accepting incoming connections
|
/// Pause accepting incoming connections
|
||||||
|
@ -126,8 +123,8 @@ impl Server {
|
||||||
/// If socket contains some pending connection, they might be dropped.
|
/// If socket contains some pending connection, they might be dropped.
|
||||||
/// All opened connection remains active.
|
/// All opened connection remains active.
|
||||||
pub fn pause(&self) -> impl Future<Output = ()> {
|
pub fn pause(&self) -> impl Future<Output = ()> {
|
||||||
let (tx, rx) = oneshot::channel();
|
let (tx, rx) = oneshot::oneshot();
|
||||||
let _ = self.0.send(ServerCommand::Pause(tx));
|
let _ = self.0.try_send(ServerCommand::Pause(tx));
|
||||||
async move {
|
async move {
|
||||||
let _ = rx.await;
|
let _ = rx.await;
|
||||||
}
|
}
|
||||||
|
@ -135,8 +132,8 @@ impl Server {
|
||||||
|
|
||||||
/// Resume accepting incoming connections
|
/// Resume accepting incoming connections
|
||||||
pub fn resume(&self) -> impl Future<Output = ()> {
|
pub fn resume(&self) -> impl Future<Output = ()> {
|
||||||
let (tx, rx) = oneshot::channel();
|
let (tx, rx) = oneshot::oneshot();
|
||||||
let _ = self.0.send(ServerCommand::Resume(tx));
|
let _ = self.0.try_send(ServerCommand::Resume(tx));
|
||||||
async move {
|
async move {
|
||||||
let _ = rx.await;
|
let _ = rx.await;
|
||||||
}
|
}
|
||||||
|
@ -146,8 +143,8 @@ impl Server {
|
||||||
///
|
///
|
||||||
/// If server starts with `spawn()` method, then spawned thread get terminated.
|
/// If server starts with `spawn()` method, then spawned thread get terminated.
|
||||||
pub fn stop(&self, graceful: bool) -> impl Future<Output = ()> {
|
pub fn stop(&self, graceful: bool) -> impl Future<Output = ()> {
|
||||||
let (tx, rx) = oneshot::channel();
|
let (tx, rx) = oneshot::oneshot();
|
||||||
let _ = self.0.send(ServerCommand::Stop {
|
let _ = self.0.try_send(ServerCommand::Stop {
|
||||||
graceful,
|
graceful,
|
||||||
completion: Some(tx),
|
completion: Some(tx),
|
||||||
});
|
});
|
||||||
|
@ -170,8 +167,8 @@ impl Future for Server {
|
||||||
let this = self.get_mut();
|
let this = self.get_mut();
|
||||||
|
|
||||||
if this.1.is_none() {
|
if this.1.is_none() {
|
||||||
let (tx, rx) = oneshot::channel();
|
let (tx, rx) = oneshot::oneshot();
|
||||||
if this.0.send(ServerCommand::Notify(tx)).is_err() {
|
if this.0.try_send(ServerCommand::Notify(tx)).is_err() {
|
||||||
return Poll::Ready(Ok(()));
|
return Poll::Ready(Ok(()));
|
||||||
}
|
}
|
||||||
this.1 = Some(rx);
|
this.1 = Some(rx);
|
||||||
|
|
|
@ -2,8 +2,9 @@ use std::sync::atomic::{AtomicBool, AtomicUsize, Ordering};
|
||||||
use std::task::{Context, Poll};
|
use std::task::{Context, Poll};
|
||||||
use std::{future::Future, pin::Pin, sync::Arc, time};
|
use std::{future::Future, pin::Pin, sync::Arc, time};
|
||||||
|
|
||||||
use tokio::sync::mpsc::{unbounded_channel, UnboundedReceiver, UnboundedSender};
|
use async_channel::{unbounded, Receiver, Sender};
|
||||||
use tokio::sync::oneshot;
|
use async_oneshot as oneshot;
|
||||||
|
use futures_core::Stream as FutStream;
|
||||||
|
|
||||||
use crate::rt::time::{sleep_until, Instant, Sleep};
|
use crate::rt::time::{sleep_until, Instant, Sleep};
|
||||||
use crate::rt::{spawn, Arbiter};
|
use crate::rt::{spawn, Arbiter};
|
||||||
|
@ -55,16 +56,16 @@ thread_local! {
|
||||||
#[derive(Clone, Debug)]
|
#[derive(Clone, Debug)]
|
||||||
pub(super) struct WorkerClient {
|
pub(super) struct WorkerClient {
|
||||||
pub(super) idx: usize,
|
pub(super) idx: usize,
|
||||||
tx1: UnboundedSender<WorkerCommand>,
|
tx1: Sender<WorkerCommand>,
|
||||||
tx2: UnboundedSender<StopCommand>,
|
tx2: Sender<StopCommand>,
|
||||||
avail: WorkerAvailability,
|
avail: WorkerAvailability,
|
||||||
}
|
}
|
||||||
|
|
||||||
impl WorkerClient {
|
impl WorkerClient {
|
||||||
pub(super) fn new(
|
pub(super) fn new(
|
||||||
idx: usize,
|
idx: usize,
|
||||||
tx1: UnboundedSender<WorkerCommand>,
|
tx1: Sender<WorkerCommand>,
|
||||||
tx2: UnboundedSender<StopCommand>,
|
tx2: Sender<StopCommand>,
|
||||||
avail: WorkerAvailability,
|
avail: WorkerAvailability,
|
||||||
) -> Self {
|
) -> Self {
|
||||||
WorkerClient {
|
WorkerClient {
|
||||||
|
@ -76,7 +77,9 @@ impl WorkerClient {
|
||||||
}
|
}
|
||||||
|
|
||||||
pub(super) fn send(&self, msg: Connection) -> Result<(), Connection> {
|
pub(super) fn send(&self, msg: Connection) -> Result<(), Connection> {
|
||||||
self.tx1.send(WorkerCommand(msg)).map_err(|msg| msg.0 .0)
|
self.tx1
|
||||||
|
.try_send(WorkerCommand(msg))
|
||||||
|
.map_err(|msg| msg.into_inner().0)
|
||||||
}
|
}
|
||||||
|
|
||||||
pub(super) fn available(&self) -> bool {
|
pub(super) fn available(&self) -> bool {
|
||||||
|
@ -84,8 +87,8 @@ impl WorkerClient {
|
||||||
}
|
}
|
||||||
|
|
||||||
pub(super) fn stop(&self, graceful: bool) -> oneshot::Receiver<bool> {
|
pub(super) fn stop(&self, graceful: bool) -> oneshot::Receiver<bool> {
|
||||||
let (result, rx) = oneshot::channel();
|
let (result, rx) = oneshot::oneshot();
|
||||||
let _ = self.tx2.send(StopCommand { graceful, result });
|
let _ = self.tx2.try_send(StopCommand { graceful, result });
|
||||||
rx
|
rx
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
@ -121,8 +124,8 @@ impl WorkerAvailability {
|
||||||
/// Worker accepts Socket objects via unbounded channel and starts stream
|
/// Worker accepts Socket objects via unbounded channel and starts stream
|
||||||
/// processing.
|
/// processing.
|
||||||
pub(super) struct Worker {
|
pub(super) struct Worker {
|
||||||
rx: UnboundedReceiver<WorkerCommand>,
|
rx: Receiver<WorkerCommand>,
|
||||||
rx2: UnboundedReceiver<StopCommand>,
|
rx2: Receiver<StopCommand>,
|
||||||
services: Vec<WorkerService>,
|
services: Vec<WorkerService>,
|
||||||
availability: WorkerAvailability,
|
availability: WorkerAvailability,
|
||||||
conns: Counter,
|
conns: Counter,
|
||||||
|
@ -161,8 +164,8 @@ impl Worker {
|
||||||
availability: WorkerAvailability,
|
availability: WorkerAvailability,
|
||||||
shutdown_timeout: time::Duration,
|
shutdown_timeout: time::Duration,
|
||||||
) -> WorkerClient {
|
) -> WorkerClient {
|
||||||
let (tx1, rx1) = unbounded_channel();
|
let (tx1, rx1) = unbounded();
|
||||||
let (tx2, rx2) = unbounded_channel();
|
let (tx2, rx2) = unbounded();
|
||||||
let avail = availability.clone();
|
let avail = availability.clone();
|
||||||
|
|
||||||
Arbiter::default().exec_fn(move || {
|
Arbiter::default().exec_fn(move || {
|
||||||
|
@ -185,8 +188,8 @@ impl Worker {
|
||||||
}
|
}
|
||||||
|
|
||||||
async fn create(
|
async fn create(
|
||||||
rx: UnboundedReceiver<WorkerCommand>,
|
rx: Receiver<WorkerCommand>,
|
||||||
rx2: UnboundedReceiver<StopCommand>,
|
rx2: Receiver<StopCommand>,
|
||||||
factories: Vec<Box<dyn InternalServiceFactory>>,
|
factories: Vec<Box<dyn InternalServiceFactory>>,
|
||||||
availability: WorkerAvailability,
|
availability: WorkerAvailability,
|
||||||
shutdown_timeout: time::Duration,
|
shutdown_timeout: time::Duration,
|
||||||
|
@ -329,8 +332,10 @@ impl Future for Worker {
|
||||||
|
|
||||||
fn poll(mut self: Pin<&mut Self>, cx: &mut Context<'_>) -> Poll<Self::Output> {
|
fn poll(mut self: Pin<&mut Self>, cx: &mut Context<'_>) -> Poll<Self::Output> {
|
||||||
// `StopWorker` message handler
|
// `StopWorker` message handler
|
||||||
if let Poll::Ready(Some(StopCommand { graceful, result })) =
|
if let Poll::Ready(Some(StopCommand {
|
||||||
Pin::new(&mut self.rx2).poll_recv(cx)
|
graceful,
|
||||||
|
mut result,
|
||||||
|
})) = Pin::new(&mut self.rx2).poll_next(cx)
|
||||||
{
|
{
|
||||||
self.availability.set(false);
|
self.availability.set(false);
|
||||||
let num = num_connections();
|
let num = num_connections();
|
||||||
|
@ -470,7 +475,7 @@ impl Future for Worker {
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
match Pin::new(&mut self.rx).poll_recv(cx) {
|
match Pin::new(&mut self.rx).poll_next(cx) {
|
||||||
// handle incoming io stream
|
// handle incoming io stream
|
||||||
Poll::Ready(Some(WorkerCommand(msg))) => {
|
Poll::Ready(Some(WorkerCommand(msg))) => {
|
||||||
let guard = self.conns.get();
|
let guard = self.conns.get();
|
||||||
|
@ -573,8 +578,8 @@ mod tests {
|
||||||
#[crate::rt_test]
|
#[crate::rt_test]
|
||||||
#[allow(clippy::mutex_atomic)]
|
#[allow(clippy::mutex_atomic)]
|
||||||
async fn basics() {
|
async fn basics() {
|
||||||
let (_tx1, rx1) = unbounded_channel();
|
let (_tx1, rx1) = unbounded();
|
||||||
let (tx2, rx2) = unbounded_channel();
|
let (tx2, rx2) = unbounded();
|
||||||
let (sync_tx, _sync_rx) = std::sync::mpsc::channel();
|
let (sync_tx, _sync_rx) = std::sync::mpsc::channel();
|
||||||
let poll = mio::Poll::new().unwrap();
|
let poll = mio::Poll::new().unwrap();
|
||||||
let waker = Arc::new(mio::Waker::new(poll.registry(), mio::Token(1)).unwrap());
|
let waker = Arc::new(mio::Waker::new(poll.registry(), mio::Token(1)).unwrap());
|
||||||
|
@ -639,8 +644,8 @@ mod tests {
|
||||||
// shutdown
|
// shutdown
|
||||||
let g = MAX_CONNS_COUNTER.with(|conns| conns.get());
|
let g = MAX_CONNS_COUNTER.with(|conns| conns.get());
|
||||||
|
|
||||||
let (tx, rx) = oneshot::channel();
|
let (tx, rx) = oneshot::oneshot();
|
||||||
tx2.send(StopCommand {
|
tx2.try_send(StopCommand {
|
||||||
graceful: true,
|
graceful: true,
|
||||||
result: tx,
|
result: tx,
|
||||||
})
|
})
|
||||||
|
@ -653,8 +658,8 @@ mod tests {
|
||||||
let _ = rx.await;
|
let _ = rx.await;
|
||||||
|
|
||||||
// force shutdown
|
// force shutdown
|
||||||
let (_tx1, rx1) = unbounded_channel();
|
let (_tx1, rx1) = unbounded();
|
||||||
let (tx2, rx2) = unbounded_channel();
|
let (tx2, rx2) = unbounded();
|
||||||
let avail = WorkerAvailability::new(AcceptNotify::new(waker, sync_tx.clone()));
|
let avail = WorkerAvailability::new(AcceptNotify::new(waker, sync_tx.clone()));
|
||||||
let f = SrvFactory {
|
let f = SrvFactory {
|
||||||
st: st.clone(),
|
st: st.clone(),
|
||||||
|
@ -683,8 +688,8 @@ mod tests {
|
||||||
let _ = lazy(|cx| Pin::new(&mut worker).poll(cx)).await;
|
let _ = lazy(|cx| Pin::new(&mut worker).poll(cx)).await;
|
||||||
assert!(avail.available());
|
assert!(avail.available());
|
||||||
|
|
||||||
let (tx, rx) = oneshot::channel();
|
let (tx, rx) = oneshot::oneshot();
|
||||||
tx2.send(StopCommand {
|
tx2.try_send(StopCommand {
|
||||||
graceful: false,
|
graceful: false,
|
||||||
result: tx,
|
result: tx,
|
||||||
})
|
})
|
||||||
|
|
Loading…
Add table
Add a link
Reference in a new issue