merge actix-rt

This commit is contained in:
Nikolay Kim 2020-03-29 13:59:17 +06:00
parent 4ec01db40a
commit 7df3cc59a1
86 changed files with 582 additions and 587 deletions

View file

@ -2,9 +2,11 @@
members = [ members = [
"ntex", "ntex",
"ntex-codec", "ntex-codec",
"ntex-macros",
"ntex-router", "ntex-router",
"ntex-rt",
"ntex-service", "ntex-service",
"ntex-web-macros", # "ntex-web-macros",
"actix-net/actix-service", "actix-net/actix-service",
"actix-net/router", "actix-net/router",
@ -13,12 +15,10 @@ members = [
[patch.crates-io] [patch.crates-io]
ntex = { path = "ntex" } ntex = { path = "ntex" }
ntex-codec = { path = "ntex-codec" } ntex-codec = { path = "ntex-codec" }
ntex-macros = { path = "ntex-macros" }
ntex-router = { path = "ntex-router" } ntex-router = { path = "ntex-router" }
ntex-rt = { path = "ntex-rt" }
ntex-service = { path = "ntex-service" } ntex-service = { path = "ntex-service" }
ntex-web-macros = { path = "ntex-web-macros" }
actix-service = { path = "actix-net/actix-service" }
actix-router = { path = "actix-net/router" }
actix-rt = { path = "actix-net/actix-rt" }
actix-macros = { path = "actix-net/actix-macros" }
bytestring = { path = "actix-net/string" } bytestring = { path = "actix-net/string" }

View file

@ -1 +0,0 @@
../LICENSE-APACHE

View file

@ -1 +0,0 @@
../LICENSE-MIT

View file

@ -1 +0,0 @@
../LICENSE-APACHE

View file

@ -1 +0,0 @@
../LICENSE-MIT

1
ntex-codec/LICENSE Symbolic link
View file

@ -0,0 +1 @@
../LICENSE

View file

@ -1 +0,0 @@
../LICENSE-APACHE

View file

@ -1 +0,0 @@
../LICENSE-MIT

View file

@ -1,12 +1,12 @@
[package] [package]
name = "actix-macros" name = "ntex-macros"
version = "0.1.1" version = "0.1.0"
authors = ["Nikolay Kim <fafhrd91@gmail.com>"] authors = ["Nikolay Kim <fafhrd91@gmail.com>"]
description = "Actix runtime macros" description = "Ntex runtime macros"
repository = "https://github.com/actix/actix-net" repository = "https://github.com/ntex-rs/ntex"
documentation = "https://docs.rs/actix-macros/" documentation = "https://docs.rs/ntex-macros/"
categories = ["network-programming", "asynchronous"] categories = ["network-programming", "asynchronous"]
license = "MIT/Apache-2.0" license = "MIT"
edition = "2018" edition = "2018"
[lib] [lib]
@ -17,4 +17,4 @@ quote = "^1"
syn = { version = "^1", features = ["full"] } syn = { version = "^1", features = ["full"] }
[dev-dependencies] [dev-dependencies]
actix-rt = { version = "1.0.0" } ntex = { version = "0.1.1" }

1
ntex-macros/LICENSE Symbolic link
View file

@ -0,0 +1 @@
../LICENSE

View file

@ -9,7 +9,7 @@ use quote::quote;
/// ## Usage /// ## Usage
/// ///
/// ```rust /// ```rust
/// #[actix_rt::main] /// #[ntex::main]
/// async fn main() { /// async fn main() {
/// println!("Hello world"); /// println!("Hello world");
/// } /// }
@ -35,7 +35,7 @@ pub fn main(_: TokenStream, item: TokenStream) -> TokenStream {
(quote! { (quote! {
#(#attrs)* #(#attrs)*
#vis #sig { #vis #sig {
actix_rt::System::new(stringify!(#name)) ntex_rt::System::new(stringify!(#name))
.block_on(async move { #body }) .block_on(async move { #body })
} }
}) })
@ -47,7 +47,7 @@ pub fn main(_: TokenStream, item: TokenStream) -> TokenStream {
/// ## Usage /// ## Usage
/// ///
/// ```no_run /// ```no_run
/// #[actix_rt::test] /// #[ntex::test]
/// async fn my_test() { /// async fn my_test() {
/// assert!(true); /// assert!(true);
/// } /// }
@ -81,7 +81,7 @@ pub fn test(_: TokenStream, item: TokenStream) -> TokenStream {
quote! { quote! {
#(#attrs)* #(#attrs)*
fn #name() #ret { fn #name() #ret {
actix_rt::System::new("test") ntex_rt::System::new("test")
.block_on(async { #body }) .block_on(async { #body })
} }
} }
@ -90,7 +90,7 @@ pub fn test(_: TokenStream, item: TokenStream) -> TokenStream {
#[test] #[test]
#(#attrs)* #(#attrs)*
fn #name() #ret { fn #name() #ret {
actix_rt::System::new("test") ntex_rt::System::new("test")
.block_on(async { #body }) .block_on(async { #body })
} }
} }

1
ntex-router/LICENSE Symbolic link
View file

@ -0,0 +1 @@
../LICENSE

View file

@ -2,6 +2,10 @@
## [1.0.0] - 2019-12-11 ## [1.0.0] - 2019-12-11
* Rename crate
## [1.0.0] - 2019-12-11
* Update dependencies * Update dependencies
## [1.0.0-alpha.3] - 2019-12-07 ## [1.0.0-alpha.3] - 2019-12-07

View file

@ -1,23 +1,22 @@
[package] [package]
name = "actix-rt" name = "ntex-rt"
version = "1.0.0" version = "1.0.0"
authors = ["Nikolay Kim <fafhrd91@gmail.com>"] authors = ["Nikolay Kim <fafhrd91@gmail.com>"]
description = "Actix runtime" description = "Actix runtime"
keywords = ["network", "framework", "async", "futures"] keywords = ["network", "framework", "async", "futures"]
homepage = "https://actix.rs" homepage = "https://ntex.rs"
repository = "https://github.com/actix/actix-net.git" repository = "https://github.com/ntex-rs/ntex.git"
documentation = "https://docs.rs/actix-rt/" documentation = "https://docs.rs/ntex-rt/"
categories = ["network-programming", "asynchronous"] categories = ["network-programming", "asynchronous"]
license = "MIT/Apache-2.0" license = "MIT"
edition = "2018" edition = "2018"
[lib] [lib]
name = "actix_rt" name = "ntex_rt"
path = "src/lib.rs" path = "src/lib.rs"
[dependencies] [dependencies]
actix-macros = "0.1.0" ntex-macros = "0.1.0"
actix-threadpool = "0.3" actix-threadpool = "0.3"
futures = "0.3.1" futures = "0.3.1"
copyless = "0.1.4"
tokio = { version = "0.2.6", default-features=false, features = ["rt-core", "rt-util", "io-driver", "tcp", "uds", "udp", "time", "signal", "stream"] } tokio = { version = "0.2.6", default-features=false, features = ["rt-core", "rt-util", "io-driver", "tcp", "uds", "udp", "time", "signal", "stream"] }

1
ntex-rt/LICENSE Symbolic link
View file

@ -0,0 +1 @@
../LICENSE

View file

@ -1,5 +1,5 @@
use std::any::{Any, TypeId}; use std::any::{Any, TypeId};
use std::cell::{Cell, RefCell}; use std::cell::RefCell;
use std::collections::HashMap; use std::collections::HashMap;
use std::pin::Pin; use std::pin::Pin;
use std::sync::atomic::{AtomicUsize, Ordering}; use std::sync::atomic::{AtomicUsize, Ordering};
@ -9,22 +9,20 @@ use std::{fmt, thread};
use futures::channel::mpsc::{unbounded, UnboundedReceiver, UnboundedSender}; use futures::channel::mpsc::{unbounded, UnboundedReceiver, UnboundedSender};
use futures::channel::oneshot::{channel, Canceled, Sender}; use futures::channel::oneshot::{channel, Canceled, Sender};
use futures::{future, Future, FutureExt, Stream}; use futures::{future, Future, FutureExt, Stream};
use tokio::task::LocalSet;
use crate::runtime::Runtime; use super::runtime::Runtime;
use crate::system::System; use super::system::System;
use copyless::BoxHelper;
thread_local!( thread_local!(
static ADDR: RefCell<Option<Arbiter>> = RefCell::new(None); static ADDR: RefCell<Option<Arbiter>> = RefCell::new(None);
static RUNNING: Cell<bool> = Cell::new(false); static STORAGE: RefCell<HashMap<TypeId, Box<dyn Any>>> =
static Q: RefCell<Vec<Pin<Box<dyn Future<Output = ()>>>>> = RefCell::new(Vec::new()); RefCell::new(HashMap::new());
static STORAGE: RefCell<HashMap<TypeId, Box<dyn Any>>> = RefCell::new(HashMap::new());
); );
pub(crate) static COUNT: AtomicUsize = AtomicUsize::new(0); pub(super) static COUNT: AtomicUsize = AtomicUsize::new(0);
pub(crate) enum ArbiterCommand { pub(super) enum ArbiterCommand {
Stop, Stop,
Execute(Box<dyn Future<Output = ()> + Unpin + Send>), Execute(Box<dyn Future<Output = ()> + Unpin + Send>),
ExecuteFn(Box<dyn FnExec>), ExecuteFn(Box<dyn FnExec>),
@ -62,14 +60,14 @@ impl Default for Arbiter {
} }
impl Arbiter { impl Arbiter {
pub(crate) fn new_system() -> Self { pub(super) fn new_system(local: &LocalSet) -> Self {
let (tx, rx) = unbounded(); let (tx, rx) = unbounded();
let arb = Arbiter::with_sender(tx); let arb = Arbiter::with_sender(tx);
ADDR.with(|cell| *cell.borrow_mut() = Some(arb.clone())); ADDR.with(|cell| *cell.borrow_mut() = Some(arb.clone()));
RUNNING.with(|cell| cell.set(false));
STORAGE.with(|cell| cell.borrow_mut().clear()); STORAGE.with(|cell| cell.borrow_mut().clear());
Arbiter::spawn(ArbiterController { stop: None, rx });
local.spawn_local(ArbiterController { stop: None, rx });
arb arb
} }
@ -104,7 +102,6 @@ impl Arbiter {
let arb = Arbiter::with_sender(arb_tx); let arb = Arbiter::with_sender(arb_tx);
let (stop, stop_rx) = channel(); let (stop, stop_rx) = channel();
RUNNING.with(|cell| cell.set(true));
STORAGE.with(|cell| cell.borrow_mut().clear()); STORAGE.with(|cell| cell.borrow_mut().clear());
System::set_current(sys); System::set_current(sys);
@ -142,44 +139,17 @@ impl Arbiter {
} }
} }
pub(crate) fn run_system(rt: Option<&Runtime>) {
RUNNING.with(|cell| cell.set(true));
Q.with(|cell| {
let mut v = cell.borrow_mut();
for fut in v.drain(..) {
if let Some(rt) = rt {
rt.spawn(fut);
} else {
tokio::task::spawn_local(fut);
}
}
});
}
pub(crate) fn stop_system() {
RUNNING.with(|cell| cell.set(false));
}
/// Spawn a future on the current thread. This does not create a new Arbiter /// Spawn a future on the current thread. This does not create a new Arbiter
/// or Arbiter address, it is simply a helper for spawning futures on the current /// or Arbiter address, it is simply a helper for spawning futures on the current
/// thread. /// thread.
///
/// Panics if arbiter is not started.
#[inline]
pub fn spawn<F>(future: F) pub fn spawn<F>(future: F)
where where
F: Future<Output = ()> + 'static, F: Future<Output = ()> + 'static,
{ {
RUNNING.with(move |cell| { tokio::task::spawn_local(future);
if cell.get() {
// Spawn the future on running executor
tokio::task::spawn_local(future);
} else {
// Box the future and push it to the queue, this results in double boxing
// because the executor boxes the future again, but works for now
Q.with(move |cell| {
cell.borrow_mut()
.push(unsafe { Pin::new_unchecked(Box::alloc().init(future)) })
});
}
});
} }
/// Executes a future on the current thread. This does not create a new Arbiter /// Executes a future on the current thread. This does not create a new Arbiter
@ -237,7 +207,9 @@ impl Arbiter {
/// Set item to arbiter storage /// Set item to arbiter storage
pub fn set_item<T: 'static>(item: T) { pub fn set_item<T: 'static>(item: T) {
STORAGE.with(move |cell| cell.borrow_mut().insert(TypeId::of::<T>(), Box::new(item))); STORAGE.with(move |cell| {
cell.borrow_mut().insert(TypeId::of::<T>(), Box::new(item))
});
} }
/// Check if arbiter storage contains item /// Check if arbiter storage contains item
@ -273,7 +245,9 @@ impl Arbiter {
let mut st = cell.borrow_mut(); let mut st = cell.borrow_mut();
let item = st let item = st
.get_mut(&TypeId::of::<T>()) .get_mut(&TypeId::of::<T>())
.and_then(|boxed| (&mut **boxed as &mut (dyn Any + 'static)).downcast_mut()) .and_then(|boxed| {
(&mut **boxed as &mut (dyn Any + 'static)).downcast_mut()
})
.unwrap(); .unwrap();
f(item) f(item)
}) })
@ -342,21 +316,24 @@ impl Future for ArbiterController {
} }
#[derive(Debug)] #[derive(Debug)]
pub(crate) enum SystemCommand { pub(super) enum SystemCommand {
Exit(i32), Exit(i32),
RegisterArbiter(usize, Arbiter), RegisterArbiter(usize, Arbiter),
UnregisterArbiter(usize), UnregisterArbiter(usize),
} }
#[derive(Debug)] #[derive(Debug)]
pub(crate) struct SystemArbiter { pub(super) struct SystemArbiter {
stop: Option<Sender<i32>>, stop: Option<Sender<i32>>,
commands: UnboundedReceiver<SystemCommand>, commands: UnboundedReceiver<SystemCommand>,
arbiters: HashMap<usize, Arbiter>, arbiters: HashMap<usize, Arbiter>,
} }
impl SystemArbiter { impl SystemArbiter {
pub(crate) fn new(stop: Sender<i32>, commands: UnboundedReceiver<SystemCommand>) -> Self { pub(super) fn new(
stop: Sender<i32>,
commands: UnboundedReceiver<SystemCommand>,
) -> Self {
SystemArbiter { SystemArbiter {
commands, commands,
stop: Some(stop), stop: Some(stop),
@ -396,7 +373,7 @@ impl Future for SystemArbiter {
} }
} }
pub trait FnExec: Send + 'static { pub(super) trait FnExec: Send + 'static {
fn call_box(self: Box<Self>); fn call_box(self: Box<Self>);
} }

View file

@ -6,9 +6,9 @@ use futures::channel::oneshot::{channel, Receiver};
use futures::future::{lazy, Future, FutureExt}; use futures::future::{lazy, Future, FutureExt};
use tokio::task::LocalSet; use tokio::task::LocalSet;
use crate::arbiter::{Arbiter, SystemArbiter}; use super::arbiter::{Arbiter, SystemArbiter};
use crate::runtime::Runtime; use super::runtime::Runtime;
use crate::system::System; use super::system::System;
/// Builder struct for a actix runtime. /// Builder struct for a actix runtime.
/// ///
@ -24,7 +24,7 @@ pub struct Builder {
} }
impl Builder { impl Builder {
pub(crate) fn new() -> Self { pub(super) fn new() -> Self {
Builder { Builder {
name: Cow::Borrowed("actix"), name: Cow::Borrowed("actix"),
stop_on_panic: false, stop_on_panic: false,
@ -56,7 +56,7 @@ impl Builder {
/// Create new System that can run asynchronously. /// Create new System that can run asynchronously.
/// ///
/// This method panics if it cannot start the system arbiter /// This method panics if it cannot start the system arbiter
pub(crate) fn build_async(self, local: &LocalSet) -> AsyncSystemRunner { pub(super) fn build_async(self, local: &LocalSet) -> AsyncSystemRunner {
self.create_async_runtime(local) self.create_async_runtime(local)
} }
@ -74,7 +74,11 @@ impl Builder {
let (stop_tx, stop) = channel(); let (stop_tx, stop) = channel();
let (sys_sender, sys_receiver) = unbounded(); let (sys_sender, sys_receiver) = unbounded();
let system = System::construct(sys_sender, Arbiter::new_system(), self.stop_on_panic); let system = System::construct(
sys_sender,
Arbiter::new_system(local),
self.stop_on_panic,
);
// system arbiter // system arbiter
let arb = SystemArbiter::new(stop_tx, sys_receiver); let arb = SystemArbiter::new(stop_tx, sys_receiver);
@ -92,12 +96,15 @@ impl Builder {
let (stop_tx, stop) = channel(); let (stop_tx, stop) = channel();
let (sys_sender, sys_receiver) = unbounded(); let (sys_sender, sys_receiver) = unbounded();
let system = System::construct(sys_sender, Arbiter::new_system(), self.stop_on_panic); let mut rt = Runtime::new().unwrap();
// system arbiter // system arbiter
let system = System::construct(
sys_sender,
Arbiter::new_system(rt.local()),
self.stop_on_panic,
);
let arb = SystemArbiter::new(stop_tx, sys_receiver); let arb = SystemArbiter::new(stop_tx, sys_receiver);
let mut rt = Runtime::new().unwrap();
rt.spawn(arb); rt.spawn(arb);
// init system arbiter and run configuration method // init system arbiter and run configuration method
@ -108,7 +115,7 @@ impl Builder {
} }
#[derive(Debug)] #[derive(Debug)]
pub(crate) struct AsyncSystemRunner { pub(super) struct AsyncSystemRunner {
stop: Receiver<i32>, stop: Receiver<i32>,
system: System, system: System,
} }
@ -116,29 +123,27 @@ pub(crate) struct AsyncSystemRunner {
impl AsyncSystemRunner { impl AsyncSystemRunner {
/// This function will start event loop and returns a future that /// This function will start event loop and returns a future that
/// resolves once the `System::stop()` function is called. /// resolves once the `System::stop()` function is called.
pub(crate) fn run_nonblocking(self) -> impl Future<Output = Result<(), io::Error>> + Send { pub(super) fn run_nonblocking(
self,
) -> impl Future<Output = Result<(), io::Error>> + Send {
let AsyncSystemRunner { stop, .. } = self; let AsyncSystemRunner { stop, .. } = self;
// run loop // run loop
lazy(|_| { lazy(|_| async {
Arbiter::run_system(None); let res = match stop.await {
async { Ok(code) => {
let res = match stop.await { if code != 0 {
Ok(code) => { Err(io::Error::new(
if code != 0 { io::ErrorKind::Other,
Err(io::Error::new( format!("Non-zero exit code: {}", code),
io::ErrorKind::Other, ))
format!("Non-zero exit code: {}", code), } else {
)) Ok(())
} else {
Ok(())
}
} }
Err(e) => Err(io::Error::new(io::ErrorKind::Other, e)), }
}; Err(e) => Err(io::Error::new(io::ErrorKind::Other, e)),
Arbiter::stop_system(); };
return res; return res;
}
}) })
.flatten() .flatten()
} }
@ -160,7 +165,6 @@ impl SystemRunner {
let SystemRunner { mut rt, stop, .. } = self; let SystemRunner { mut rt, stop, .. } = self;
// run loop // run loop
Arbiter::run_system(Some(&rt));
let result = match rt.block_on(stop) { let result = match rt.block_on(stop) {
Ok(code) => { Ok(code) => {
if code != 0 { if code != 0 {
@ -174,18 +178,24 @@ impl SystemRunner {
} }
Err(e) => Err(io::Error::new(io::ErrorKind::Other, e)), Err(e) => Err(io::Error::new(io::ErrorKind::Other, e)),
}; };
Arbiter::stop_system();
result result
} }
/// Execute a future and wait for result. /// Execute a future and wait for result.
#[inline]
pub fn block_on<F, O>(&mut self, fut: F) -> O pub fn block_on<F, O>(&mut self, fut: F) -> O
where where
F: Future<Output = O> + 'static, F: Future<Output = O>,
{ {
Arbiter::run_system(Some(&self.rt)); self.rt.block_on(fut)
let res = self.rt.block_on(fut); }
Arbiter::stop_system();
res /// Execute a function with enabled executor.
#[inline]
pub fn exec<F, R>(&mut self, f: F) -> R
where
F: FnOnce() -> R,
{
self.rt.block_on(lazy(|_| f()))
} }
} }

View file

@ -1,10 +1,4 @@
//! A runtime implementation that runs everything on the current thread. //! A runtime implementation that runs everything on the current thread.
#![deny(rust_2018_idioms, warnings)]
#![allow(clippy::type_complexity)]
#[cfg(not(test))] // Work around for rust-lang/rust#62127
pub use actix_macros::{main, test};
mod arbiter; mod arbiter;
mod builder; mod builder;
mod runtime; mod runtime;
@ -15,6 +9,9 @@ pub use self::builder::{Builder, SystemRunner};
pub use self::runtime::Runtime; pub use self::runtime::Runtime;
pub use self::system::System; pub use self::system::System;
#[cfg(not(test))] // Work around for rust-lang/rust#62127
pub use ntex_macros::{main, test};
#[doc(hidden)] #[doc(hidden)]
pub use actix_threadpool as blocking; pub use actix_threadpool as blocking;
@ -23,6 +20,7 @@ pub use actix_threadpool as blocking;
/// # Panics /// # Panics
/// ///
/// This function panics if actix system is not running. /// This function panics if actix system is not running.
#[inline]
pub fn spawn<F>(f: F) pub fn spawn<F>(f: F)
where where
F: futures::Future<Output = ()> + 'static, F: futures::Future<Output = ()> + 'static,
@ -49,7 +47,7 @@ pub mod net {
pub use tokio::net::{TcpListener, TcpStream}; pub use tokio::net::{TcpListener, TcpStream};
#[cfg(unix)] #[cfg(unix)]
mod unix { pub mod unix {
pub use tokio::net::{UnixDatagram, UnixListener, UnixStream}; pub use tokio::net::{UnixDatagram, UnixListener, UnixStream};
} }

View file

@ -30,6 +30,10 @@ impl Runtime {
}) })
} }
pub(super) fn local(&self) -> &LocalSet {
&self.local
}
/// Spawn a future onto the single-threaded runtime. /// Spawn a future onto the single-threaded runtime.
/// ///
/// See [module level][mod] documentation for more details. /// See [module level][mod] documentation for more details.
@ -84,7 +88,7 @@ impl Runtime {
/// complete execution by calling `block_on` or `run`. /// complete execution by calling `block_on` or `run`.
pub fn block_on<F>(&mut self, f: F) -> F::Output pub fn block_on<F>(&mut self, f: F) -> F::Output
where where
F: Future + 'static, F: Future,
{ {
let res = self.local.block_on(&mut self.rt, f); let res = self.local.block_on(&mut self.rt, f);
res res

View file

@ -6,8 +6,8 @@ use std::sync::atomic::{AtomicUsize, Ordering};
use futures::channel::mpsc::UnboundedSender; use futures::channel::mpsc::UnboundedSender;
use tokio::task::LocalSet; use tokio::task::LocalSet;
use crate::arbiter::{Arbiter, SystemCommand}; use super::arbiter::{Arbiter, SystemCommand};
use crate::builder::{Builder, SystemRunner}; use super::builder::{Builder, SystemRunner};
static SYSTEM_COUNT: AtomicUsize = AtomicUsize::new(0); static SYSTEM_COUNT: AtomicUsize = AtomicUsize::new(0);
@ -26,7 +26,7 @@ thread_local!(
impl System { impl System {
/// Constructs new system and sets it as current /// Constructs new system and sets it as current
pub(crate) fn construct( pub(super) fn construct(
sys: UnboundedSender<SystemCommand>, sys: UnboundedSender<SystemCommand>,
arbiter: Arbiter, arbiter: Arbiter,
stop_on_panic: bool, stop_on_panic: bool,
@ -80,7 +80,7 @@ impl System {
} }
/// Set current running system. /// Set current running system.
pub(crate) fn is_set() -> bool { pub(super) fn is_set() -> bool {
CURRENT.with(|cell| cell.borrow().is_some()) CURRENT.with(|cell| cell.borrow().is_some())
} }
@ -118,7 +118,7 @@ impl System {
let _ = self.sys.unbounded_send(SystemCommand::Exit(code)); let _ = self.sys.unbounded_send(SystemCommand::Exit(code));
} }
pub(crate) fn sys(&self) -> &UnboundedSender<SystemCommand> { pub(super) fn sys(&self) -> &UnboundedSender<SystemCommand> {
&self.sys &self.sys
} }

View file

@ -20,4 +20,4 @@ futures-util = "0.3.1"
pin-project = "0.4.6" pin-project = "0.4.6"
[dev-dependencies] [dev-dependencies]
actix-rt = "1.0.0" ntex-rt = "1.0"

1
ntex-service/LICENSE Symbolic link
View file

@ -0,0 +1 @@
../LICENSE

View file

@ -313,7 +313,7 @@ mod tests {
} }
} }
#[actix_rt::test] #[ntex_rt::test]
async fn test_poll_ready() { async fn test_poll_ready() {
let cnt = Rc::new(Cell::new(0)); let cnt = Rc::new(Cell::new(0));
let mut srv = pipeline(Srv1(cnt.clone())).and_then(Srv2(cnt.clone())); let mut srv = pipeline(Srv1(cnt.clone())).and_then(Srv2(cnt.clone()));
@ -322,7 +322,7 @@ mod tests {
assert_eq!(cnt.get(), 2); assert_eq!(cnt.get(), 2);
} }
#[actix_rt::test] #[ntex_rt::test]
async fn test_call() { async fn test_call() {
let cnt = Rc::new(Cell::new(0)); let cnt = Rc::new(Cell::new(0));
let mut srv = pipeline(Srv1(cnt.clone())).and_then(Srv2(cnt)); let mut srv = pipeline(Srv1(cnt.clone())).and_then(Srv2(cnt));
@ -331,7 +331,7 @@ mod tests {
assert_eq!(res.unwrap(), (("srv1", "srv2"))); assert_eq!(res.unwrap(), (("srv1", "srv2")));
} }
#[actix_rt::test] #[ntex_rt::test]
async fn test_new_service() { async fn test_new_service() {
let cnt = Rc::new(Cell::new(0)); let cnt = Rc::new(Cell::new(0));
let cnt2 = cnt.clone(); let cnt2 = cnt.clone();

View file

@ -311,7 +311,7 @@ mod tests {
} }
} }
#[actix_rt::test] #[ntex_rt::test]
async fn test_service() { async fn test_service() {
let mut srv = pipeline(|r: &'static str| ok(r)) let mut srv = pipeline(|r: &'static str| ok(r))
.and_then_apply_fn(Srv, |req: &'static str, s| { .and_then_apply_fn(Srv, |req: &'static str, s| {
@ -325,7 +325,7 @@ mod tests {
assert_eq!(res.unwrap(), ("srv", ())); assert_eq!(res.unwrap(), ("srv", ()));
} }
#[actix_rt::test] #[ntex_rt::test]
async fn test_service_factory() { async fn test_service_factory() {
let new_srv = let new_srv =
pipeline_factory(|| ok::<_, ()>(fn_service(|r: &'static str| ok(r)))) pipeline_factory(|| ok::<_, ()>(fn_service(|r: &'static str| ok(r))))

View file

@ -238,7 +238,7 @@ mod tests {
} }
} }
#[actix_rt::test] #[ntex_rt::test]
async fn test_call() { async fn test_call() {
let mut srv = pipeline(apply_fn(Srv, |req: &'static str, srv| { let mut srv = pipeline(apply_fn(Srv, |req: &'static str, srv| {
let fut = srv.call(()); let fut = srv.call(());
@ -255,7 +255,7 @@ mod tests {
assert_eq!(res.unwrap(), (("srv", ()))); assert_eq!(res.unwrap(), (("srv", ())));
} }
#[actix_rt::test] #[ntex_rt::test]
async fn test_new_service() { async fn test_new_service() {
let new_srv = pipeline_factory(apply_fn_factory( let new_srv = pipeline_factory(apply_fn_factory(
|| ok::<_, ()>(Srv), || ok::<_, ()>(Srv),

View file

@ -23,7 +23,7 @@ where
/// ///
/// ```rust /// ```rust
/// use std::io; /// use std::io;
/// use actix_service::{fn_factory, fn_service, Service, ServiceFactory}; /// use ntex_service::{fn_factory, fn_service, Service, ServiceFactory};
/// use futures_util::future::ok; /// use futures_util::future::ok;
/// ///
/// /// Service that divides two usize values. /// /// Service that divides two usize values.
@ -35,7 +35,7 @@ where
/// } /// }
/// } /// }
/// ///
/// #[actix_rt::main] /// #[ntex::main]
/// async fn main() -> io::Result<()> { /// async fn main() -> io::Result<()> {
/// // Create service factory that produces `div` services /// // Create service factory that produces `div` services
/// let factory = fn_factory(|| { /// let factory = fn_factory(|| {
@ -73,10 +73,10 @@ where
/// ///
/// ```rust /// ```rust
/// use std::io; /// use std::io;
/// use actix_service::{fn_factory_with_config, fn_service, Service, ServiceFactory}; /// use ntex_service::{fn_factory_with_config, fn_service, Service, ServiceFactory};
/// use futures_util::future::ok; /// use futures_util::future::ok;
/// ///
/// #[actix_rt::main] /// #[ntex::main]
/// async fn main() -> io::Result<()> { /// async fn main() -> io::Result<()> {
/// // Create service factory. factory uses config argument for /// // Create service factory. factory uses config argument for
/// // services it generates. /// // services it generates.
@ -370,7 +370,7 @@ mod tests {
use super::*; use super::*;
use crate::{Service, ServiceFactory}; use crate::{Service, ServiceFactory};
#[actix_rt::test] #[ntex_rt::test]
async fn test_fn_service() { async fn test_fn_service() {
let new_srv = fn_service(|()| ok::<_, ()>("srv")); let new_srv = fn_service(|()| ok::<_, ()>("srv"));
@ -381,7 +381,7 @@ mod tests {
assert_eq!(res.unwrap(), "srv"); assert_eq!(res.unwrap(), "srv");
} }
#[actix_rt::test] #[ntex_rt::test]
async fn test_fn_service_service() { async fn test_fn_service_service() {
let mut srv = fn_service(|()| ok::<_, ()>("srv")); let mut srv = fn_service(|()| ok::<_, ()>("srv"));
@ -391,7 +391,7 @@ mod tests {
assert_eq!(res.unwrap(), "srv"); assert_eq!(res.unwrap(), "srv");
} }
#[actix_rt::test] #[ntex_rt::test]
async fn test_fn_service_with_config() { async fn test_fn_service_with_config() {
let new_srv = fn_factory_with_config(|cfg: usize| { let new_srv = fn_factory_with_config(|cfg: usize| {
ok::<_, ()>(fn_service(move |()| ok::<_, ()>(("srv", cfg)))) ok::<_, ()>(fn_service(move |()| ok::<_, ()>(("srv", cfg))))

View file

@ -226,14 +226,14 @@ mod tests {
} }
} }
#[actix_rt::test] #[ntex_rt::test]
async fn test_poll_ready() { async fn test_poll_ready() {
let mut srv = Srv.map(|_| "ok"); let mut srv = Srv.map(|_| "ok");
let res = lazy(|cx| srv.poll_ready(cx)).await; let res = lazy(|cx| srv.poll_ready(cx)).await;
assert_eq!(res, Poll::Ready(Ok(()))); assert_eq!(res, Poll::Ready(Ok(())));
} }
#[actix_rt::test] #[ntex_rt::test]
async fn test_call() { async fn test_call() {
let mut srv = Srv.map(|_| "ok"); let mut srv = Srv.map(|_| "ok");
let res = srv.call(()).await; let res = srv.call(()).await;
@ -241,7 +241,7 @@ mod tests {
assert_eq!(res.unwrap(), "ok"); assert_eq!(res.unwrap(), "ok");
} }
#[actix_rt::test] #[ntex_rt::test]
async fn test_new_service() { async fn test_new_service() {
let new_srv = (|| ok::<_, ()>(Srv)).into_factory().map(|_| "ok"); let new_srv = (|| ok::<_, ()>(Srv)).into_factory().map(|_| "ok");
let mut srv = new_srv.new_service(&()).await.unwrap(); let mut srv = new_srv.new_service(&()).await.unwrap();

View file

@ -228,14 +228,14 @@ mod tests {
} }
} }
#[actix_rt::test] #[ntex_rt::test]
async fn test_poll_ready() { async fn test_poll_ready() {
let mut srv = Srv.map_err(|_| "error"); let mut srv = Srv.map_err(|_| "error");
let res = lazy(|cx| srv.poll_ready(cx)).await; let res = lazy(|cx| srv.poll_ready(cx)).await;
assert_eq!(res, Poll::Ready(Err("error"))); assert_eq!(res, Poll::Ready(Err("error")));
} }
#[actix_rt::test] #[ntex_rt::test]
async fn test_call() { async fn test_call() {
let mut srv = Srv.map_err(|_| "error"); let mut srv = Srv.map_err(|_| "error");
let res = srv.call(()).await; let res = srv.call(()).await;
@ -243,7 +243,7 @@ mod tests {
assert_eq!(res.err().unwrap(), "error"); assert_eq!(res.err().unwrap(), "error");
} }
#[actix_rt::test] #[ntex_rt::test]
async fn test_new_service() { async fn test_new_service() {
let new_srv = (|| ok::<_, ()>(Srv)).into_factory().map_err(|_| "error"); let new_srv = (|| ok::<_, ()>(Srv)).into_factory().map_err(|_| "error");
let mut srv = new_srv.new_service(&()).await.unwrap(); let mut srv = new_srv.new_service(&()).await.unwrap();

View file

@ -306,7 +306,7 @@ mod tests {
} }
} }
#[actix_rt::test] #[ntex_rt::test]
async fn test_poll_ready() { async fn test_poll_ready() {
let cnt = Rc::new(Cell::new(0)); let cnt = Rc::new(Cell::new(0));
let mut srv = pipeline(Srv1(cnt.clone())).then(Srv2(cnt.clone())); let mut srv = pipeline(Srv1(cnt.clone())).then(Srv2(cnt.clone()));
@ -315,7 +315,7 @@ mod tests {
assert_eq!(cnt.get(), 2); assert_eq!(cnt.get(), 2);
} }
#[actix_rt::test] #[ntex_rt::test]
async fn test_call() { async fn test_call() {
let cnt = Rc::new(Cell::new(0)); let cnt = Rc::new(Cell::new(0));
let mut srv = pipeline(Srv1(cnt.clone())).then(Srv2(cnt)); let mut srv = pipeline(Srv1(cnt.clone())).then(Srv2(cnt));
@ -329,7 +329,7 @@ mod tests {
assert_eq!(res.unwrap(), (("srv2", "err"))); assert_eq!(res.unwrap(), (("srv2", "err")));
} }
#[actix_rt::test] #[ntex_rt::test]
async fn test_factory() { async fn test_factory() {
let cnt = Rc::new(Cell::new(0)); let cnt = Rc::new(Cell::new(0));
let cnt2 = cnt.clone(); let cnt2 = cnt.clone();

1
ntex-web-macros/LICENSE Symbolic link
View file

@ -0,0 +1 @@
../LICENSE

View file

@ -36,15 +36,14 @@ compress = ["flate2", "brotli2"]
cookie = ["coo-kie", "coo-kie/percent-encode"] cookie = ["coo-kie", "coo-kie/percent-encode"]
[dependencies] [dependencies]
ntex-codec = { path = "../ntex-codec" } ntex-codec = "0.1"
ntex-router = { path = "../ntex-router" } ntex-macros = "0.1"
ntex-service = { path = "../ntex-service" } ntex-rt = "1.0"
ntex-web-macros = { path = "../ntex-web-macros" } ntex-router = "0.3"
ntex-service = "1.0"
ntex-web-macros = "0.1"
actix-macros = "0.1.0"
actix-rt = "1.0.0"
actix-threadpool = "0.3.1" actix-threadpool = "0.3.1"
base64 = "0.11" base64 = "0.11"
bitflags = "1.2" bitflags = "1.2"
bytes = "0.5.3" bytes = "0.5.3"
@ -96,7 +95,7 @@ mio-uds = { version = "0.6.7" }
brotli2 = { version="0.3.2", optional = true } brotli2 = { version="0.3.2", optional = true }
flate2 = { version = "1.0.13", optional = true } flate2 = { version = "1.0.13", optional = true }
tokio = "0.2.4" tokio = { version = "0.2.6", default-features=false, features = ["rt-core", "rt-util", "io-driver", "tcp", "uds", "udp", "time", "signal", "stream"] }
[dev-dependencies] [dev-dependencies]
futures = "0.3.1" futures = "0.3.1"

View file

@ -1,25 +0,0 @@
Copyright (c) 2017 Nikolay Kim
Permission is hereby granted, free of charge, to any
person obtaining a copy of this software and associated
documentation files (the "Software"), to deal in the
Software without restriction, including without
limitation the rights to use, copy, modify, merge,
publish, distribute, sublicense, and/or sell copies of
the Software, and to permit persons to whom the Software
is furnished to do so, subject to the following
conditions:
The above copyright notice and this permission notice
shall be included in all copies or substantial portions
of the Software.
THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF
ANY KIND, EXPRESS OR IMPLIED, INCLUDING BUT NOT LIMITED
TO THE WARRANTIES OF MERCHANTABILITY, FITNESS FOR A
PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT
SHALL THE AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY
CLAIM, DAMAGES OR OTHER LIABILITY, WHETHER IN AN ACTION
OF CONTRACT, TORT OR OTHERWISE, ARISING FROM, OUT OF OR
IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER
DEALINGS IN THE SOFTWARE.

1
ntex/LICENSE Symbolic link
View file

@ -0,0 +1 @@
../LICENSE

View file

@ -98,7 +98,7 @@ mod tests {
use super::*; use super::*;
use futures::future::lazy; use futures::future::lazy;
#[crate::test] #[ntex_rt::test]
async fn test_condition() { async fn test_condition() {
let mut cond = Condition::new(); let mut cond = Condition::new();
let mut waiter = cond.wait(); let mut waiter = cond.wait();

View file

@ -195,7 +195,7 @@ mod tests {
use futures::future::lazy; use futures::future::lazy;
use futures::{Stream, StreamExt}; use futures::{Stream, StreamExt};
#[crate::test] #[ntex_rt::test]
async fn test_mpsc() { async fn test_mpsc() {
let (tx, mut rx) = channel(); let (tx, mut rx) = channel();
tx.send("test").unwrap(); tx.send("test").unwrap();

View file

@ -255,7 +255,7 @@ mod tests {
use super::*; use super::*;
use futures::future::lazy; use futures::future::lazy;
#[crate::test] #[ntex_rt::test]
async fn test_oneshot() { async fn test_oneshot() {
let (tx, rx) = channel(); let (tx, rx) = channel();
tx.send("test").unwrap(); tx.send("test").unwrap();
@ -282,7 +282,7 @@ mod tests {
assert!(rx.await.is_err()); assert!(rx.await.is_err());
} }
#[crate::test] #[ntex_rt::test]
async fn test_pool() { async fn test_pool() {
let (tx, rx) = pool().channel(); let (tx, rx) = pool().channel();
tx.send("test").unwrap(); tx.send("test").unwrap();

View file

@ -525,7 +525,7 @@ mod tests {
} }
} }
#[crate::test] #[ntex_rt::test]
async fn test_static_str() { async fn test_static_str() {
assert_eq!(Body::from("").size(), BodySize::Sized(0)); assert_eq!(Body::from("").size(), BodySize::Sized(0));
assert_eq!(Body::from("test").size(), BodySize::Sized(4)); assert_eq!(Body::from("test").size(), BodySize::Sized(4));
@ -538,7 +538,7 @@ mod tests {
); );
} }
#[crate::test] #[ntex_rt::test]
async fn test_static_bytes() { async fn test_static_bytes() {
assert_eq!(Body::from(b"test".as_ref()).size(), BodySize::Sized(4)); assert_eq!(Body::from(b"test".as_ref()).size(), BodySize::Sized(4));
assert_eq!(Body::from(b"test".as_ref()).get_ref(), b"test"); assert_eq!(Body::from(b"test".as_ref()).get_ref(), b"test");
@ -558,7 +558,7 @@ mod tests {
); );
} }
#[crate::test] #[ntex_rt::test]
async fn test_vec() { async fn test_vec() {
assert_eq!(Body::from(Vec::from("test")).size(), BodySize::Sized(4)); assert_eq!(Body::from(Vec::from("test")).size(), BodySize::Sized(4));
assert_eq!(Body::from(Vec::from("test")).get_ref(), b"test"); assert_eq!(Body::from(Vec::from("test")).get_ref(), b"test");
@ -573,7 +573,7 @@ mod tests {
); );
} }
#[crate::test] #[ntex_rt::test]
async fn test_bytes() { async fn test_bytes() {
let mut b = Bytes::from("test"); let mut b = Bytes::from("test");
assert_eq!(Body::from(b.clone()).size(), BodySize::Sized(4)); assert_eq!(Body::from(b.clone()).size(), BodySize::Sized(4));
@ -586,7 +586,7 @@ mod tests {
); );
} }
#[crate::test] #[ntex_rt::test]
async fn test_bytes_mut() { async fn test_bytes_mut() {
let mut b = BytesMut::from("test"); let mut b = BytesMut::from("test");
assert_eq!(Body::from(b.clone()).size(), BodySize::Sized(4)); assert_eq!(Body::from(b.clone()).size(), BodySize::Sized(4));
@ -599,7 +599,7 @@ mod tests {
); );
} }
#[crate::test] #[ntex_rt::test]
async fn test_string() { async fn test_string() {
let mut b = "test".to_owned(); let mut b = "test".to_owned();
assert_eq!(Body::from(b.clone()).size(), BodySize::Sized(4)); assert_eq!(Body::from(b.clone()).size(), BodySize::Sized(4));
@ -614,20 +614,20 @@ mod tests {
); );
} }
#[crate::test] #[ntex_rt::test]
async fn test_unit() { async fn test_unit() {
assert_eq!(().size(), BodySize::Empty); assert_eq!(().size(), BodySize::Empty);
assert!(poll_fn(|cx| ().poll_next_chunk(cx)).await.is_none()); assert!(poll_fn(|cx| ().poll_next_chunk(cx)).await.is_none());
} }
#[crate::test] #[ntex_rt::test]
async fn test_box() { async fn test_box() {
let mut val = Box::new(()); let mut val = Box::new(());
assert_eq!(val.size(), BodySize::Empty); assert_eq!(val.size(), BodySize::Empty);
assert!(poll_fn(|cx| val.poll_next_chunk(cx)).await.is_none()); assert!(poll_fn(|cx| val.poll_next_chunk(cx)).await.is_none());
} }
#[crate::test] #[ntex_rt::test]
async fn test_body_eq() { async fn test_body_eq() {
assert!(Body::None == Body::None); assert!(Body::None == Body::None);
assert!(Body::None != Body::Empty); assert!(Body::None != Body::Empty);
@ -640,14 +640,14 @@ mod tests {
assert!(Body::Bytes(Bytes::from_static(b"1")) != Body::None); assert!(Body::Bytes(Bytes::from_static(b"1")) != Body::None);
} }
#[crate::test] #[ntex_rt::test]
async fn test_body_debug() { async fn test_body_debug() {
assert!(format!("{:?}", Body::None).contains("Body::None")); assert!(format!("{:?}", Body::None).contains("Body::None"));
assert!(format!("{:?}", Body::Empty).contains("Body::Empty")); assert!(format!("{:?}", Body::Empty).contains("Body::Empty"));
assert!(format!("{:?}", Body::Bytes(Bytes::from_static(b"1"))).contains("1")); assert!(format!("{:?}", Body::Bytes(Bytes::from_static(b"1"))).contains("1"));
} }
#[crate::test] #[ntex_rt::test]
async fn test_serde_json() { async fn test_serde_json() {
use serde_json::json; use serde_json::json;
assert_eq!( assert_eq!(
@ -663,7 +663,7 @@ mod tests {
mod body_stream { mod body_stream {
use super::*; use super::*;
#[crate::test] #[ntex_rt::test]
async fn skips_empty_chunks() { async fn skips_empty_chunks() {
let mut body = BodyStream::new(stream::iter( let mut body = BodyStream::new(stream::iter(
["1", "", "2"] ["1", "", "2"]
@ -684,7 +684,7 @@ mod tests {
mod sized_stream { mod sized_stream {
use super::*; use super::*;
#[crate::test] #[ntex_rt::test]
async fn skips_empty_chunks() { async fn skips_empty_chunks() {
let mut body = SizedStream::new( let mut body = SizedStream::new(
2, 2,

View file

@ -149,7 +149,7 @@ impl ClientBuilder {
mod tests { mod tests {
use super::*; use super::*;
#[crate::test] #[ntex_rt::test]
async fn client_basic_auth() { async fn client_basic_auth() {
let client = ClientBuilder::new().basic_auth("username", Some("password")); let client = ClientBuilder::new().basic_auth("username", Some("password"));
assert_eq!( assert_eq!(
@ -176,7 +176,7 @@ mod tests {
); );
} }
#[crate::test] #[ntex_rt::test]
async fn client_bearer_auth() { async fn client_bearer_auth() {
let client = ClientBuilder::new().bearer_auth("someS3cr3tAutht0k3n"); let client = ClientBuilder::new().bearer_auth("someS3cr3tAutht0k3n");
assert_eq!( assert_eq!(

View file

@ -94,7 +94,7 @@ where
fn call(&mut self, req: Connect) -> Self::Future { fn call(&mut self, req: Connect) -> Self::Future {
// start support future // start support future
actix_rt::spawn(ConnectorPoolSupport { crate::rt::spawn(ConnectorPoolSupport {
connector: self.0.clone(), connector: self.0.clone(),
inner: self.1.clone(), inner: self.1.clone(),
}); });
@ -133,7 +133,7 @@ where
)) ))
} else { } else {
let (snd, connection) = handshake(io).await?; let (snd, connection) = handshake(io).await?;
actix_rt::spawn(connection.map(|_| ())); crate::rt::spawn(connection.map(|_| ()));
Ok(IoConnection::new( Ok(IoConnection::new(
ConnectionType::H2(snd), ConnectionType::H2(snd),
Instant::now(), Instant::now(),
@ -322,7 +322,7 @@ where
{ {
if let Some(timeout) = self.disconnect_timeout { if let Some(timeout) = self.disconnect_timeout {
if let ConnectionType::H1(io) = conn.io { if let ConnectionType::H1(io) = conn.io {
actix_rt::spawn(CloseConnection::new(io, timeout)) crate::rt::spawn(CloseConnection::new(io, timeout))
} }
} }
} else { } else {
@ -334,7 +334,7 @@ where
Poll::Ready(Ok(n)) if n > 0 => { Poll::Ready(Ok(n)) if n > 0 => {
if let Some(timeout) = self.disconnect_timeout { if let Some(timeout) = self.disconnect_timeout {
if let ConnectionType::H1(io) = io { if let ConnectionType::H1(io) = io {
actix_rt::spawn(CloseConnection::new( crate::rt::spawn(CloseConnection::new(
io, timeout, io, timeout,
)) ))
} }
@ -368,7 +368,7 @@ where
self.acquired -= 1; self.acquired -= 1;
if let Some(timeout) = self.disconnect_timeout { if let Some(timeout) = self.disconnect_timeout {
if let ConnectionType::H1(io) = io { if let ConnectionType::H1(io) = io {
actix_rt::spawn(CloseConnection::new(io, timeout)) crate::rt::spawn(CloseConnection::new(io, timeout))
} }
} }
self.check_availibility(); self.check_availibility();
@ -510,7 +510,7 @@ where
inner: Rc<RefCell<Inner<Io>>>, inner: Rc<RefCell<Inner<Io>>>,
fut: F, fut: F,
) { ) {
actix_rt::spawn(OpenWaitingConnection { crate::rt::spawn(OpenWaitingConnection {
key, key,
fut, fut,
h2: None, h2: None,
@ -546,7 +546,7 @@ where
if let Some(ref mut h2) = this.h2 { if let Some(ref mut h2) = this.h2 {
return match Pin::new(h2).poll(cx) { return match Pin::new(h2).poll(cx) {
Poll::Ready(Ok((snd, connection))) => { Poll::Ready(Ok((snd, connection))) => {
actix_rt::spawn(connection.map(|_| ())); crate::rt::spawn(connection.map(|_| ()));
let rx = this.rx.take().unwrap(); let rx = this.rx.take().unwrap();
let _ = rx.send(Ok(IoConnection::new( let _ = rx.send(Ok(IoConnection::new(
ConnectionType::H2(snd), ConnectionType::H2(snd),

View file

@ -577,7 +577,7 @@ mod tests {
use super::*; use super::*;
use crate::http::client::Client; use crate::http::client::Client;
#[crate::test] #[ntex_rt::test]
async fn test_debug() { async fn test_debug() {
let request = Client::new().get("/").header("x-test", "111"); let request = Client::new().get("/").header("x-test", "111");
let repr = format!("{:?}", request); let repr = format!("{:?}", request);
@ -585,7 +585,7 @@ mod tests {
assert!(repr.contains("x-test")); assert!(repr.contains("x-test"));
} }
#[crate::test] #[ntex_rt::test]
async fn test_basics() { async fn test_basics() {
let mut req = Client::new() let mut req = Client::new()
.put("/") .put("/")
@ -612,7 +612,7 @@ mod tests {
let _ = req.send_body(""); let _ = req.send_body("");
} }
#[crate::test] #[ntex_rt::test]
async fn test_client_header() { async fn test_client_header() {
let req = Client::build() let req = Client::build()
.header(header::CONTENT_TYPE, "111") .header(header::CONTENT_TYPE, "111")
@ -630,7 +630,7 @@ mod tests {
); );
} }
#[crate::test] #[ntex_rt::test]
async fn test_client_header_override() { async fn test_client_header_override() {
let req = Client::build() let req = Client::build()
.header(header::CONTENT_TYPE, "111") .header(header::CONTENT_TYPE, "111")
@ -649,7 +649,7 @@ mod tests {
); );
} }
#[crate::test] #[ntex_rt::test]
async fn client_basic_auth() { async fn client_basic_auth() {
let req = Client::new() let req = Client::new()
.get("/") .get("/")
@ -676,7 +676,7 @@ mod tests {
); );
} }
#[crate::test] #[ntex_rt::test]
async fn client_bearer_auth() { async fn client_bearer_auth() {
let req = Client::new().get("/").bearer_auth("someS3cr3tAutht0k3n"); let req = Client::new().get("/").bearer_auth("someS3cr3tAutht0k3n");
assert_eq!( assert_eq!(
@ -690,7 +690,7 @@ mod tests {
); );
} }
#[crate::test] #[ntex_rt::test]
async fn client_query() { async fn client_query() {
let req = Client::new() let req = Client::new()
.get("/") .get("/")

View file

@ -381,7 +381,7 @@ mod tests {
use crate::http::client::test::TestResponse; use crate::http::client::test::TestResponse;
use crate::http::header; use crate::http::header;
#[crate::test] #[ntex_rt::test]
async fn test_body() { async fn test_body() {
let mut req = TestResponse::with_header(header::CONTENT_LENGTH, "xxxx").finish(); let mut req = TestResponse::with_header(header::CONTENT_LENGTH, "xxxx").finish();
match req.body().await.err().unwrap() { match req.body().await.err().unwrap() {
@ -429,7 +429,7 @@ mod tests {
} }
} }
#[crate::test] #[ntex_rt::test]
async fn test_json_body() { async fn test_json_body() {
let mut req = TestResponse::default().finish(); let mut req = TestResponse::default().finish();
let json = JsonBody::<_, MyObject>::new(&mut req).await; let json = JsonBody::<_, MyObject>::new(&mut req).await;

View file

@ -5,7 +5,6 @@ use std::rc::Rc;
use std::task::{Context, Poll}; use std::task::{Context, Poll};
use std::time::Duration; use std::time::Duration;
use actix_rt::time::{delay_for, Delay};
use bytes::Bytes; use bytes::Bytes;
use derive_more::From; use derive_more::From;
use futures::{Future, Stream}; use futures::{Future, Stream};
@ -16,6 +15,7 @@ use crate::http::body::{Body, BodyStream};
use crate::http::error::HttpError; use crate::http::error::HttpError;
use crate::http::header::{self, HeaderMap, HeaderName, IntoHeaderValue}; use crate::http::header::{self, HeaderMap, HeaderName, IntoHeaderValue};
use crate::http::RequestHead; use crate::http::RequestHead;
use crate::rt::time::{delay_for, Delay};
#[cfg(feature = "compress")] #[cfg(feature = "compress")]
use crate::http::encoding::Decoder; use crate::http::encoding::Decoder;

View file

@ -410,7 +410,7 @@ mod tests {
use super::*; use super::*;
use crate::http::client::Client; use crate::http::client::Client;
#[crate::test] #[ntex_rt::test]
async fn test_debug() { async fn test_debug() {
let request = Client::new().ws("/").header("x-test", "111"); let request = Client::new().ws("/").header("x-test", "111");
let repr = format!("{:?}", request); let repr = format!("{:?}", request);
@ -418,7 +418,7 @@ mod tests {
assert!(repr.contains("x-test")); assert!(repr.contains("x-test"));
} }
#[crate::test] #[ntex_rt::test]
async fn test_header_override() { async fn test_header_override() {
let req = Client::build() let req = Client::build()
.header(header::CONTENT_TYPE, "111") .header(header::CONTENT_TYPE, "111")
@ -437,7 +437,7 @@ mod tests {
); );
} }
#[crate::test] #[ntex_rt::test]
async fn basic_auth() { async fn basic_auth() {
let req = Client::new() let req = Client::new()
.ws("/") .ws("/")
@ -464,7 +464,7 @@ mod tests {
); );
} }
#[crate::test] #[ntex_rt::test]
async fn bearer_auth() { async fn bearer_auth() {
let req = Client::new().ws("/").bearer_auth("someS3cr3tAutht0k3n"); let req = Client::new().ws("/").bearer_auth("someS3cr3tAutht0k3n");
assert_eq!( assert_eq!(
@ -480,7 +480,7 @@ mod tests {
} }
#[cfg(feature = "cookie")] #[cfg(feature = "cookie")]
#[crate::test] #[ntex_rt::test]
async fn basics() { async fn basics() {
let req = Client::new() let req = Client::new()
.ws("http://localhost/") .ws("http://localhost/")

View file

@ -266,7 +266,7 @@ impl DateService {
// periodic date update // periodic date update
let s = self.clone(); let s = self.clone();
actix_rt::spawn(delay_for(Duration::from_millis(500)).then(move |_| { crate::rt::spawn(delay_for(Duration::from_millis(500)).then(move |_| {
s.0.reset(); s.0.reset();
future::ready(()) future::ready(())
})); }));
@ -293,7 +293,7 @@ mod tests {
assert_eq!(DATE_VALUE_LENGTH, "Sun, 06 Nov 1994 08:49:37 GMT".len()); assert_eq!(DATE_VALUE_LENGTH, "Sun, 06 Nov 1994 08:49:37 GMT".len());
} }
#[crate::test] #[ntex_rt::test]
async fn test_date() { async fn test_date() {
let settings = ServiceConfig::new(KeepAlive::Os, 0, 0, false, None); let settings = ServiceConfig::new(KeepAlive::Os, 0, 0, false, None);
let mut buf1 = BytesMut::with_capacity(DATE_VALUE_LENGTH + 10); let mut buf1 = BytesMut::with_capacity(DATE_VALUE_LENGTH + 10);

View file

@ -913,7 +913,7 @@ mod tests {
use crate::http::test::TestBuffer; use crate::http::test::TestBuffer;
use crate::IntoService; use crate::IntoService;
#[crate::test] #[ntex_rt::test]
async fn test_req_parse_err() { async fn test_req_parse_err() {
lazy(|cx| { lazy(|cx| {
let buf = TestBuffer::new("GET /test HTTP/1\r\n\r\n"); let buf = TestBuffer::new("GET /test HTTP/1\r\n\r\n");

View file

@ -228,7 +228,7 @@ mod tests {
use super::*; use super::*;
use futures::future::poll_fn; use futures::future::poll_fn;
#[crate::test] #[ntex_rt::test]
async fn test_unread_data() { async fn test_unread_data() {
let (_, mut payload) = Payload::create(false); let (_, mut payload) = Payload::create(false);

View file

@ -134,7 +134,7 @@ where
on_connect.set(&mut req.extensions_mut()); on_connect.set(&mut req.extensions_mut());
} }
actix_rt::spawn(ServiceResponse::< crate::rt::spawn(ServiceResponse::<
S::Future, S::Future,
S::Response, S::Response,
S::Error, S::Error,

View file

@ -307,15 +307,18 @@ pub fn server<F: ServiceFactory<TcpStream>>(factory: F) -> TestServer {
// run server in separate thread // run server in separate thread
thread::spawn(move || { thread::spawn(move || {
let sys = System::new("actix-test-server"); let mut sys = System::new("actix-test-server");
let tcp = net::TcpListener::bind("127.0.0.1:0").unwrap(); let tcp = net::TcpListener::bind("127.0.0.1:0").unwrap();
let local_addr = tcp.local_addr().unwrap(); let local_addr = tcp.local_addr().unwrap();
Server::build() sys.exec(|| {
.listen("test", tcp, factory)? Server::build()
.workers(1) .listen("test", tcp, factory)?
.disable_signals() .workers(1)
.start(); .disable_signals()
.start();
Ok::<_, io::Error>(())
})?;
tx.send((System::current(), local_addr)).unwrap(); tx.send((System::current(), local_addr)).unwrap();
sys.run() sys.run()

View file

@ -15,7 +15,7 @@
#[macro_use] #[macro_use]
extern crate log; extern crate log;
pub use actix_macros::{main, test}; pub use ntex_macros::{main, test};
pub mod channel; pub mod channel;
pub mod codec; pub mod codec;

View file

@ -1,2 +1,2 @@
//! A runtime implementation that runs everything on the current thread. //! A runtime implementation that runs everything on the current thread.
pub use actix_rt::*; pub use ntex_rt::*;

View file

@ -2,11 +2,12 @@ use std::sync::mpsc as sync_mpsc;
use std::time::Duration; use std::time::Duration;
use std::{io, thread}; use std::{io, thread};
use actix_rt::time::{delay_until, Instant};
use actix_rt::System;
use log::{error, info}; use log::{error, info};
use slab::Slab; use slab::Slab;
use crate::rt::time::{delay_until, Instant};
use crate::rt::System;
use super::server::Server; use super::server::Server;
use super::socket::{SocketAddr, SocketListener, StdListener}; use super::socket::{SocketAddr, SocketListener, StdListener};
use super::worker::{Conn, WorkerClient}; use super::worker::{Conn, WorkerClient};

View file

@ -3,9 +3,6 @@ use std::task::{Context, Poll};
use std::time::Duration; use std::time::Duration;
use std::{io, mem, net}; use std::{io, mem, net};
use actix_rt::net::TcpStream;
use actix_rt::time::{delay_until, Instant};
use actix_rt::{spawn, System};
use futures::channel::mpsc::{unbounded, UnboundedReceiver}; use futures::channel::mpsc::{unbounded, UnboundedReceiver};
use futures::channel::oneshot; use futures::channel::oneshot;
use futures::future::ready; use futures::future::ready;
@ -15,6 +12,10 @@ use log::{error, info};
use net2::TcpBuilder; use net2::TcpBuilder;
use num_cpus; use num_cpus;
use crate::rt::net::TcpStream;
use crate::rt::time::{delay_until, Instant};
use crate::rt::{spawn, System};
use super::accept::{AcceptLoop, AcceptNotify, Command}; use super::accept::{AcceptLoop, AcceptNotify, Command};
use super::config::{ConfiguredService, ServiceConfig}; use super::config::{ConfiguredService, ServiceConfig};
use super::server::{Server, ServerCommand}; use super::server::{Server, ServerCommand};
@ -187,7 +188,7 @@ impl ServerBuilder {
/// Add new unix domain service to the server. /// Add new unix domain service to the server.
pub fn bind_uds<F, U, N>(self, name: N, addr: U, factory: F) -> io::Result<Self> pub fn bind_uds<F, U, N>(self, name: N, addr: U, factory: F) -> io::Result<Self>
where where
F: ServiceFactory<actix_rt::net::UnixStream>, F: ServiceFactory<crate::rt::net::UnixStream>,
N: AsRef<str>, N: AsRef<str>,
U: AsRef<std::path::Path>, U: AsRef<std::path::Path>,
{ {
@ -217,7 +218,7 @@ impl ServerBuilder {
factory: F, factory: F,
) -> io::Result<Self> ) -> io::Result<Self>
where where
F: ServiceFactory<actix_rt::net::UnixStream>, F: ServiceFactory<crate::rt::net::UnixStream>,
{ {
use std::net::{IpAddr, Ipv4Addr, SocketAddr}; use std::net::{IpAddr, Ipv4Addr, SocketAddr};
let token = self.token.next(); let token = self.token.next();

View file

@ -1,10 +1,10 @@
use std::collections::HashMap; use std::collections::HashMap;
use std::{fmt, io, net}; use std::{fmt, io, net};
use actix_rt::net::TcpStream;
use futures::future::{ok, Future, FutureExt, LocalBoxFuture}; use futures::future::{ok, Future, FutureExt, LocalBoxFuture};
use log::error; use log::error;
use crate::rt::net::TcpStream;
use crate::service; use crate::service;
use crate::util::counter::CounterGuard; use crate::util::counter::CounterGuard;

View file

@ -3,11 +3,11 @@ use std::net::SocketAddr;
use std::task::{Context, Poll}; use std::task::{Context, Poll};
use std::time::Duration; use std::time::Duration;
use actix_rt::spawn;
use futures::future::{err, ok, LocalBoxFuture, Ready}; use futures::future::{err, ok, LocalBoxFuture, Ready};
use futures::{FutureExt, TryFutureExt}; use futures::{FutureExt, TryFutureExt};
use log::error; use log::error;
use crate::rt::spawn;
use crate::service::{Service, ServiceFactory as ActixServiceFactory}; use crate::service::{Service, ServiceFactory as ActixServiceFactory};
use crate::util::counter::CounterGuard; use crate::util::counter::CounterGuard;

View file

@ -26,22 +26,22 @@ pub(crate) struct Signals {
#[cfg(not(unix))] #[cfg(not(unix))]
stream: Pin<Box<dyn Future<Output = io::Result<()>>>>, stream: Pin<Box<dyn Future<Output = io::Result<()>>>>,
#[cfg(unix)] #[cfg(unix)]
streams: Vec<(Signal, actix_rt::signal::unix::Signal)>, streams: Vec<(Signal, crate::rt::signal::unix::Signal)>,
} }
impl Signals { impl Signals {
pub(crate) fn start(srv: Server) -> io::Result<()> { pub(crate) fn start(srv: Server) -> io::Result<()> {
actix_rt::spawn(lazy(|_| { crate::rt::spawn(lazy(|_| {
#[cfg(not(unix))] #[cfg(not(unix))]
{ {
actix_rt::spawn(Signals { crate::rt::spawn(Signals {
srv, srv,
stream: Box::pin(actix_rt::signal::ctrl_c()), stream: Box::pin(crate::rt::signal::ctrl_c()),
}); });
} }
#[cfg(unix)] #[cfg(unix)]
{ {
use actix_rt::signal::unix; use crate::rt::signal::unix;
let mut streams = Vec::new(); let mut streams = Vec::new();
@ -63,7 +63,7 @@ impl Signals {
} }
} }
actix_rt::spawn(Signals { srv, streams }) crate::rt::spawn(Signals { srv, streams })
} }
})); }));

View file

@ -162,11 +162,11 @@ impl FromStream for TcpStream {
} }
#[cfg(all(unix))] #[cfg(all(unix))]
impl FromStream for actix_rt::net::UnixStream { impl FromStream for crate::rt::net::UnixStream {
fn from_stdstream(sock: StdStream) -> io::Result<Self> { fn from_stdstream(sock: StdStream) -> io::Result<Self> {
match sock { match sock {
StdStream::Tcp(_) => panic!("Should not happen, bug in server impl"), StdStream::Tcp(_) => panic!("Should not happen, bug in server impl"),
StdStream::Uds(stream) => actix_rt::net::UnixStream::from_std(stream), StdStream::Uds(stream) => crate::rt::net::UnixStream::from_std(stream),
} }
} }
} }

View file

@ -1,11 +1,11 @@
//! Test server //! Test server
use std::sync::mpsc; use std::sync::mpsc;
use std::{net, thread}; use std::{io, net, thread};
use actix_rt::{net::TcpStream, System};
use net2::TcpBuilder; use net2::TcpBuilder;
use super::{Server, ServerBuilder, ServiceFactory}; use crate::rt::{net::TcpStream, System};
use crate::server::{Server, ServerBuilder, ServiceFactory};
/// Start test server /// Start test server
/// ///
@ -43,15 +43,18 @@ pub fn test_server<F: ServiceFactory<TcpStream>>(factory: F) -> TestServer {
// run server in separate thread // run server in separate thread
thread::spawn(move || { thread::spawn(move || {
let sys = System::new("ntex-test-server"); let mut sys = System::new("ntex-test-server");
let tcp = net::TcpListener::bind("127.0.0.1:0").unwrap(); let tcp = net::TcpListener::bind("127.0.0.1:0").unwrap();
let local_addr = tcp.local_addr().unwrap(); let local_addr = tcp.local_addr().unwrap();
Server::build() sys.exec(|| {
.listen("test", tcp, factory)? Server::build()
.workers(1) .listen("test", tcp, factory)?
.disable_signals() .workers(1)
.start(); .disable_signals()
.start();
Ok::<_, io::Error>(())
})?;
tx.send((System::current(), local_addr)).unwrap(); tx.send((System::current(), local_addr)).unwrap();
sys.run() sys.run()
@ -71,11 +74,14 @@ where
// run server in separate thread // run server in separate thread
thread::spawn(move || { thread::spawn(move || {
let sys = System::new("actix-test-server"); let mut sys = System::new("actix-test-server");
factory(Server::build())
.workers(1) sys.exec(|| {
.disable_signals() factory(Server::build())
.start(); .workers(1)
.disable_signals()
.start();
});
tx.send(System::current()).unwrap(); tx.send(System::current()).unwrap();
sys.run() sys.run()

View file

@ -4,14 +4,14 @@ use std::sync::Arc;
use std::task::{Context, Poll}; use std::task::{Context, Poll};
use std::time; use std::time;
use actix_rt::time::{delay_until, Delay, Instant};
use actix_rt::{spawn, Arbiter};
use futures::channel::mpsc::{unbounded, UnboundedReceiver, UnboundedSender}; use futures::channel::mpsc::{unbounded, UnboundedReceiver, UnboundedSender};
use futures::channel::oneshot; use futures::channel::oneshot;
use futures::future::{join_all, LocalBoxFuture, MapOk}; use futures::future::{join_all, LocalBoxFuture, MapOk};
use futures::{Future, FutureExt, Stream, TryFutureExt}; use futures::{Future, FutureExt, Stream, TryFutureExt};
use log::{error, info, trace}; use log::{error, info, trace};
use crate::rt::time::{delay_until, Delay, Instant};
use crate::rt::{spawn, Arbiter};
use crate::util::counter::Counter; use crate::util::counter::Counter;
use super::accept::AcceptNotify; use super::accept::AcceptNotify;
@ -229,7 +229,7 @@ impl Worker {
self.services.iter_mut().for_each(|srv| { self.services.iter_mut().for_each(|srv| {
if srv.status == WorkerServiceStatus::Available { if srv.status == WorkerServiceStatus::Available {
srv.status = WorkerServiceStatus::Stopped; srv.status = WorkerServiceStatus::Stopped;
actix_rt::spawn( crate::rt::spawn(
srv.service srv.service
.call((None, ServerMessage::ForceShutdown)) .call((None, ServerMessage::ForceShutdown))
.map(|_| ()), .map(|_| ()),
@ -241,7 +241,7 @@ impl Worker {
self.services.iter_mut().for_each(move |srv| { self.services.iter_mut().for_each(move |srv| {
if srv.status == WorkerServiceStatus::Available { if srv.status == WorkerServiceStatus::Available {
srv.status = WorkerServiceStatus::Stopping; srv.status = WorkerServiceStatus::Stopping;
actix_rt::spawn( crate::rt::spawn(
srv.service srv.service
.call((None, ServerMessage::Shutdown(timeout))) .call((None, ServerMessage::Shutdown(timeout)))
.map(|_| ()), .map(|_| ()),

View file

@ -140,7 +140,7 @@ mod tests {
} }
} }
#[crate::test] #[ntex_rt::test]
async fn test_transform() { async fn test_transform() {
let wait_time = Duration::from_millis(50); let wait_time = Duration::from_millis(50);
@ -154,7 +154,7 @@ mod tests {
assert_eq!(lazy(|cx| srv.poll_ready(cx)).await, Poll::Ready(Ok(()))); assert_eq!(lazy(|cx| srv.poll_ready(cx)).await, Poll::Ready(Ok(())));
} }
#[crate::test] #[ntex_rt::test]
async fn test_newtransform() { async fn test_newtransform() {
let wait_time = Duration::from_millis(50); let wait_time = Duration::from_millis(50);

View file

@ -5,12 +5,13 @@ use std::pin::Pin;
use std::task::{Context, Poll}; use std::task::{Context, Poll};
use std::time::Duration; use std::time::Duration;
use actix_rt::time::{delay_until, Delay, Instant};
use futures::future::{ok, Ready}; use futures::future::{ok, Ready};
use super::time::{LowResTime, LowResTimeService}; use crate::rt::time::{delay_until, Delay, Instant};
use crate::{Service, ServiceFactory}; use crate::{Service, ServiceFactory};
use super::time::{LowResTime, LowResTimeService};
pub struct KeepAlive<R, E, F> { pub struct KeepAlive<R, E, F> {
f: F, f: F,
ka: Duration, ka: Duration,

View file

@ -180,7 +180,7 @@ where
let waker = self.waker.clone(); let waker = self.waker.clone();
let fut = self.service.call(request); let fut = self.service.call(request);
actix_rt::spawn(async move { crate::rt::spawn(async move {
let res = fut.await; let res = fut.await;
waker.wake(); waker.wake();
let _ = tx1.send(res); let _ = tx1.send(res);
@ -236,7 +236,7 @@ mod tests {
} }
} }
#[crate::test] #[ntex_rt::test]
async fn test_inorder() { async fn test_inorder() {
let (tx1, rx1) = oneshot::channel(); let (tx1, rx1) = oneshot::channel();
let (tx2, rx2) = oneshot::channel(); let (tx2, rx2) = oneshot::channel();
@ -248,7 +248,7 @@ mod tests {
let rx2 = rx2; let rx2 = rx2;
let rx3 = rx3; let rx3 = rx3;
let tx_stop = tx_stop; let tx_stop = tx_stop;
let _ = actix_rt::System::new("test").block_on(async { let _ = crate::rt::System::new("test").block_on(async {
let mut srv = InOrderService::new(Srv); let mut srv = InOrderService::new(Srv);
let _ = lazy(|cx| srv.poll_ready(cx)).await; let _ = lazy(|cx| srv.poll_ready(cx)).await;
@ -256,7 +256,7 @@ mod tests {
let res2 = srv.call(rx2); let res2 = srv.call(rx2);
let res3 = srv.call(rx3); let res3 = srv.call(rx3);
actix_rt::spawn(async move { crate::rt::spawn(async move {
let _ = poll_fn(|cx| { let _ = poll_fn(|cx| {
let _ = srv.poll_ready(cx); let _ = srv.poll_ready(cx);
Poll::<()>::Pending Poll::<()>::Pending
@ -269,7 +269,7 @@ mod tests {
assert_eq!(res3.await.unwrap(), 3); assert_eq!(res3.await.unwrap(), 3);
let _ = tx_stop.send(()); let _ = tx_stop.send(());
actix_rt::System::current().stop(); crate::rt::System::current().stop();
}); });
}); });

View file

@ -58,7 +58,7 @@ where
Poll::Ready(_) => match this.stream.poll_next(cx) { Poll::Ready(_) => match this.stream.poll_next(cx) {
Poll::Ready(Some(item)) => { Poll::Ready(Some(item)) => {
let stop = this.err_tx.clone(); let stop = this.err_tx.clone();
actix_rt::spawn(this.service.call(item).map(move |res| { crate::rt::spawn(this.service.call(item).map(move |res| {
if let Err(e) = res { if let Err(e) = res {
let _ = stop.send(e); let _ = stop.send(e);
} }

View file

@ -2,10 +2,10 @@ use std::convert::Infallible;
use std::task::{Context, Poll}; use std::task::{Context, Poll};
use std::time::{self, Duration, Instant}; use std::time::{self, Duration, Instant};
use actix_rt::time::delay_for;
use futures::future::{ok, ready, FutureExt, Ready}; use futures::future::{ok, ready, FutureExt, Ready};
use super::cell::Cell; use super::cell::Cell;
use crate::rt::time::delay_for;
use crate::service::{Service, ServiceFactory}; use crate::service::{Service, ServiceFactory};
#[derive(Clone, Debug)] #[derive(Clone, Debug)]
@ -79,7 +79,7 @@ impl LowResTimeService {
b.resolution b.resolution
}; };
actix_rt::spawn(delay_for(interval).then(move |_| { crate::rt::spawn(delay_for(interval).then(move |_| {
inner.get_mut().current.take(); inner.get_mut().current.take();
ready(()) ready(())
})); }));
@ -144,7 +144,7 @@ impl SystemTimeService {
b.resolution b.resolution
}; };
actix_rt::spawn(delay_for(interval).then(move |_| { crate::rt::spawn(delay_for(interval).then(move |_| {
inner.get_mut().current.take(); inner.get_mut().current.take();
ready(()) ready(())
})); }));
@ -161,7 +161,7 @@ mod tests {
/// State Under Test: Two calls of `SystemTimeService::now()` return the same value if they are done within resolution interval of `SystemTimeService`. /// State Under Test: Two calls of `SystemTimeService::now()` return the same value if they are done within resolution interval of `SystemTimeService`.
/// ///
/// Expected Behavior: Two back-to-back calls of `SystemTimeService::now()` return the same value. /// Expected Behavior: Two back-to-back calls of `SystemTimeService::now()` return the same value.
#[crate::test] #[ntex_rt::test]
async fn system_time_service_time_does_not_immediately_change() { async fn system_time_service_time_does_not_immediately_change() {
let resolution = Duration::from_millis(50); let resolution = Duration::from_millis(50);
@ -172,7 +172,7 @@ mod tests {
/// State Under Test: Two calls of `LowResTimeService::now()` return the same value if they are done within resolution interval of `SystemTimeService`. /// State Under Test: Two calls of `LowResTimeService::now()` return the same value if they are done within resolution interval of `SystemTimeService`.
/// ///
/// Expected Behavior: Two back-to-back calls of `LowResTimeService::now()` return the same value. /// Expected Behavior: Two back-to-back calls of `LowResTimeService::now()` return the same value.
#[crate::test] #[ntex_rt::test]
async fn lowres_time_service_time_does_not_immediately_change() { async fn lowres_time_service_time_does_not_immediately_change() {
let resolution = Duration::from_millis(50); let resolution = Duration::from_millis(50);
let time_service = LowResTimeService::with(resolution); let time_service = LowResTimeService::with(resolution);
@ -183,7 +183,7 @@ mod tests {
/// ///
/// Expected Behavior: Two calls of `LowResTimeService::now()` made in subsequent resolution interval return different values /// Expected Behavior: Two calls of `LowResTimeService::now()` made in subsequent resolution interval return different values
/// and second value is greater than the first one at least by a resolution interval. /// and second value is greater than the first one at least by a resolution interval.
#[crate::test] #[ntex_rt::test]
async fn system_time_service_time_updates_after_resolution_interval() { async fn system_time_service_time_updates_after_resolution_interval() {
let resolution = Duration::from_millis(100); let resolution = Duration::from_millis(100);
let wait_time = Duration::from_millis(300); let wait_time = Duration::from_millis(300);
@ -209,7 +209,7 @@ mod tests {
/// ///
/// Expected Behavior: Two calls of `LowResTimeService::now()` made in subsequent resolution interval return different values /// Expected Behavior: Two calls of `LowResTimeService::now()` made in subsequent resolution interval return different values
/// and second value is greater than the first one at least by a resolution interval. /// and second value is greater than the first one at least by a resolution interval.
#[crate::test] #[ntex_rt::test]
async fn lowres_time_service_time_updates_after_resolution_interval() { async fn lowres_time_service_time_updates_after_resolution_interval() {
let resolution = Duration::from_millis(100); let resolution = Duration::from_millis(100);
let wait_time = Duration::from_millis(300); let wait_time = Duration::from_millis(300);

View file

@ -8,9 +8,9 @@ use std::pin::Pin;
use std::task::{Context, Poll}; use std::task::{Context, Poll};
use std::{fmt, time}; use std::{fmt, time};
use actix_rt::time::{delay_for, Delay};
use futures::future::{ok, Ready}; use futures::future::{ok, Ready};
use crate::rt::time::{delay_for, Delay};
use crate::service::{IntoService, Service, Transform}; use crate::service::{IntoService, Service, Transform};
/// Applies a timeout to requests. /// Applies a timeout to requests.
@ -203,13 +203,13 @@ mod tests {
} }
fn call(&mut self, _: ()) -> Self::Future { fn call(&mut self, _: ()) -> Self::Future {
actix_rt::time::delay_for(self.0) crate::rt::time::delay_for(self.0)
.then(|_| ok::<_, ()>(())) .then(|_| ok::<_, ()>(()))
.boxed_local() .boxed_local()
} }
} }
#[crate::test] #[ntex_rt::test]
async fn test_success() { async fn test_success() {
let resolution = Duration::from_millis(100); let resolution = Duration::from_millis(100);
let wait_time = Duration::from_millis(50); let wait_time = Duration::from_millis(50);
@ -218,7 +218,7 @@ mod tests {
assert_eq!(timeout.call(()).await, Ok(())); assert_eq!(timeout.call(()).await, Ok(()));
} }
#[crate::test] #[ntex_rt::test]
async fn test_timeout() { async fn test_timeout() {
let resolution = Duration::from_millis(100); let resolution = Duration::from_millis(100);
let wait_time = Duration::from_millis(500); let wait_time = Duration::from_millis(500);
@ -227,7 +227,7 @@ mod tests {
assert_eq!(timeout.call(()).await, Err(TimeoutError::Timeout)); assert_eq!(timeout.call(()).await, Err(TimeoutError::Timeout));
} }
#[crate::test] #[ntex_rt::test]
async fn test_timeout_newservice() { async fn test_timeout_newservice() {
let resolution = Duration::from_millis(100); let resolution = Duration::from_millis(100);
let wait_time = Duration::from_millis(500); let wait_time = Duration::from_millis(500);

View file

@ -527,7 +527,7 @@ mod tests {
use crate::web::{self, DefaultError, HttpRequest, HttpResponse}; use crate::web::{self, DefaultError, HttpRequest, HttpResponse};
use crate::Service; use crate::Service;
#[crate::test] #[ntex_rt::test]
async fn test_default_resource() { async fn test_default_resource() {
let mut srv = init_service( let mut srv = init_service(
App::new() App::new()
@ -573,7 +573,7 @@ mod tests {
assert_eq!(resp.status(), StatusCode::CREATED); assert_eq!(resp.status(), StatusCode::CREATED);
} }
#[crate::test] #[ntex_rt::test]
async fn test_data_factory() { async fn test_data_factory() {
let mut srv = init_service( let mut srv = init_service(
App::new().data_factory(|| ok::<_, ()>(10usize)).service( App::new().data_factory(|| ok::<_, ()>(10usize)).service(
@ -598,7 +598,7 @@ mod tests {
assert_eq!(res.status(), StatusCode::INTERNAL_SERVER_ERROR); assert_eq!(res.status(), StatusCode::INTERNAL_SERVER_ERROR);
} }
#[crate::test] #[ntex_rt::test]
async fn test_extension() { async fn test_extension() {
let mut srv = init_service(App::new().app_data(10usize).service( let mut srv = init_service(App::new().app_data(10usize).service(
web::resource("/").to(|req: HttpRequest| async move { web::resource("/").to(|req: HttpRequest| async move {
@ -612,7 +612,7 @@ mod tests {
assert_eq!(resp.status(), StatusCode::OK); assert_eq!(resp.status(), StatusCode::OK);
} }
#[crate::test] #[ntex_rt::test]
async fn test_wrap() { async fn test_wrap() {
let mut srv = init_service( let mut srv = init_service(
App::new() App::new()
@ -632,7 +632,7 @@ mod tests {
); );
} }
#[crate::test] #[ntex_rt::test]
async fn test_router_wrap() { async fn test_router_wrap() {
let mut srv = init_service( let mut srv = init_service(
App::new() App::new()
@ -652,7 +652,7 @@ mod tests {
); );
} }
#[crate::test] #[ntex_rt::test]
async fn test_wrap_fn() { async fn test_wrap_fn() {
let mut srv = init_service( let mut srv = init_service(
App::new() App::new()
@ -679,7 +679,7 @@ mod tests {
); );
} }
#[crate::test] #[ntex_rt::test]
async fn test_router_wrap_fn() { async fn test_router_wrap_fn() {
let mut srv = init_service( let mut srv = init_service(
App::new() App::new()
@ -706,7 +706,7 @@ mod tests {
); );
} }
#[crate::test] #[ntex_rt::test]
async fn test_case_insensitive_router() { async fn test_case_insensitive_router() {
let mut srv = init_service( let mut srv = init_service(
App::new() App::new()
@ -723,7 +723,7 @@ mod tests {
assert_eq!(resp.status(), StatusCode::OK); assert_eq!(resp.status(), StatusCode::OK);
} }
#[crate::test] #[ntex_rt::test]
async fn test_external_resource() { async fn test_external_resource() {
let mut srv = init_service( let mut srv = init_service(
App::new() App::new()

View file

@ -492,7 +492,7 @@ mod tests {
} }
} }
#[crate::test] #[ntex_rt::test]
async fn test_drop_data() { async fn test_drop_data() {
let data = Arc::new(AtomicBool::new(false)); let data = Arc::new(AtomicBool::new(false));

View file

@ -249,7 +249,7 @@ mod tests {
use crate::web::{self, App, HttpRequest, HttpResponse}; use crate::web::{self, App, HttpRequest, HttpResponse};
use crate::Service; use crate::Service;
#[crate::test] #[ntex_rt::test]
async fn test_data() { async fn test_data() {
let cfg = |cfg: &mut ServiceConfig<_>| { let cfg = |cfg: &mut ServiceConfig<_>| {
cfg.data(10usize); cfg.data(10usize);
@ -264,7 +264,7 @@ mod tests {
assert_eq!(resp.status(), StatusCode::OK); assert_eq!(resp.status(), StatusCode::OK);
} }
// #[crate::test] // #[ntex_rt::test]
// async fn test_data_factory() { // async fn test_data_factory() {
// let cfg = |cfg: &mut ServiceConfig| { // let cfg = |cfg: &mut ServiceConfig| {
// cfg.data_factory(|| { // cfg.data_factory(|| {
@ -296,7 +296,7 @@ mod tests {
// assert_eq!(resp.status(), StatusCode::INTERNAL_SERVER_ERROR); // assert_eq!(resp.status(), StatusCode::INTERNAL_SERVER_ERROR);
// } // }
#[crate::test] #[ntex_rt::test]
async fn test_external_resource() { async fn test_external_resource() {
let mut srv = init_service( let mut srv = init_service(
App::new() App::new()
@ -324,7 +324,7 @@ mod tests {
assert_eq!(body, Bytes::from_static(b"https://youtube.com/watch/12345")); assert_eq!(body, Bytes::from_static(b"https://youtube.com/watch/12345"));
} }
#[crate::test] #[ntex_rt::test]
async fn test_service() { async fn test_service() {
let mut srv = init_service(App::new().configure(|cfg| { let mut srv = init_service(App::new().configure(|cfg| {
cfg.service( cfg.service(

View file

@ -140,7 +140,7 @@ mod tests {
use crate::web::{self, App, HttpResponse}; use crate::web::{self, App, HttpResponse};
use crate::Service; use crate::Service;
#[crate::test] #[ntex_rt::test]
async fn test_data_extractor() { async fn test_data_extractor() {
let mut srv = init_service(App::new().data("TEST".to_string()).service( let mut srv = init_service(App::new().data("TEST".to_string()).service(
web::resource("/").to(|data: web::Data<String>| async move { web::resource("/").to(|data: web::Data<String>| async move {
@ -163,7 +163,7 @@ mod tests {
assert_eq!(res.status(), StatusCode::INTERNAL_SERVER_ERROR); assert_eq!(res.status(), StatusCode::INTERNAL_SERVER_ERROR);
} }
#[crate::test] #[ntex_rt::test]
async fn test_app_data_extractor() { async fn test_app_data_extractor() {
let mut srv = init_service(App::new().app_data(Data::new(10usize)).service( let mut srv = init_service(App::new().app_data(Data::new(10usize)).service(
web::resource("/").to(|_: web::Data<usize>| async { HttpResponse::Ok() }), web::resource("/").to(|_: web::Data<usize>| async { HttpResponse::Ok() }),
@ -183,7 +183,7 @@ mod tests {
assert_eq!(res.status(), StatusCode::INTERNAL_SERVER_ERROR); assert_eq!(res.status(), StatusCode::INTERNAL_SERVER_ERROR);
} }
#[crate::test] #[ntex_rt::test]
async fn test_route_data_extractor() { async fn test_route_data_extractor() {
let mut srv = let mut srv =
init_service(App::new().service(web::resource("/").data(10usize).route( init_service(App::new().service(web::resource("/").data(10usize).route(
@ -209,7 +209,7 @@ mod tests {
assert_eq!(res.status(), StatusCode::INTERNAL_SERVER_ERROR); assert_eq!(res.status(), StatusCode::INTERNAL_SERVER_ERROR);
} }
#[crate::test] #[ntex_rt::test]
async fn test_override_data() { async fn test_override_data() {
let mut srv = init_service(App::new().data(1usize).service( let mut srv = init_service(App::new().data(1usize).service(
web::resource("/").data(10usize).route(web::get().to( web::resource("/").data(10usize).route(web::get().to(
@ -227,7 +227,7 @@ mod tests {
assert_eq!(resp.status(), StatusCode::OK); assert_eq!(resp.status(), StatusCode::OK);
} }
#[crate::test] #[ntex_rt::test]
async fn test_data_drop() { async fn test_data_drop() {
struct TestData(Arc<AtomicUsize>); struct TestData(Arc<AtomicUsize>);

View file

@ -280,7 +280,7 @@ tuple_from_req!(TupleFromRequest10, (0, A), (1, B), (2, C), (3, D), (4, E), (5,
// extract // extract
// } // }
// #[crate::test] // #[ntex_rt::test]
// async fn test_option() { // async fn test_option() {
// let (req, mut pl) = TestRequest::with_header( // let (req, mut pl) = TestRequest::with_header(
// header::CONTENT_TYPE, // header::CONTENT_TYPE,
@ -326,7 +326,7 @@ tuple_from_req!(TupleFromRequest10, (0, A), (1, B), (2, C), (3, D), (4, E), (5,
// assert_eq!(r, None); // assert_eq!(r, None);
// } // }
// #[crate::test] // #[ntex_rt::test]
// async fn test_result() { // async fn test_result() {
// let (req, mut pl) = TestRequest::with_header( // let (req, mut pl) = TestRequest::with_header(
// header::CONTENT_TYPE, // header::CONTENT_TYPE,

View file

@ -827,13 +827,13 @@ mod tests {
use super::*; use super::*;
#[crate::test] #[ntex_rt::test]
#[should_panic(expected = "Credentials are allowed, but the Origin is set to")] #[should_panic(expected = "Credentials are allowed, but the Origin is set to")]
async fn cors_validates_illegal_allow_credentials() { async fn cors_validates_illegal_allow_credentials() {
let _cors = Cors::new().supports_credentials().send_wildcard().finish(); let _cors = Cors::new().supports_credentials().send_wildcard().finish();
} }
#[crate::test] #[ntex_rt::test]
async fn validate_origin_allows_all_origins() { async fn validate_origin_allows_all_origins() {
let mut cors = Cors::new() let mut cors = Cors::new()
.finish() .finish()
@ -847,7 +847,7 @@ mod tests {
assert_eq!(resp.status(), StatusCode::OK); assert_eq!(resp.status(), StatusCode::OK);
} }
#[crate::test] #[ntex_rt::test]
async fn default() { async fn default() {
let mut cors = Cors::default() let mut cors = Cors::default()
.new_transform(test::ok_service()) .new_transform(test::ok_service())
@ -860,7 +860,7 @@ mod tests {
assert_eq!(resp.status(), StatusCode::OK); assert_eq!(resp.status(), StatusCode::OK);
} }
#[crate::test] #[ntex_rt::test]
async fn test_preflight() { async fn test_preflight() {
let mut cors = Cors::new() let mut cors = Cors::new()
.send_wildcard() .send_wildcard()
@ -950,7 +950,7 @@ mod tests {
assert_eq!(resp.status(), StatusCode::OK); assert_eq!(resp.status(), StatusCode::OK);
} }
// #[crate::test] // #[ntex_rt::test]
// #[should_panic(expected = "MissingOrigin")] // #[should_panic(expected = "MissingOrigin")]
// async fn test_validate_missing_origin() { // async fn test_validate_missing_origin() {
// let cors = Cors::build() // let cors = Cors::build()
@ -960,7 +960,7 @@ mod tests {
// cors.start(&req).unwrap(); // cors.start(&req).unwrap();
// } // }
#[crate::test] #[ntex_rt::test]
#[should_panic(expected = "OriginNotAllowed")] #[should_panic(expected = "OriginNotAllowed")]
async fn test_validate_not_allowed_origin() { async fn test_validate_not_allowed_origin() {
let cors = Cors::new() let cors = Cors::new()
@ -978,7 +978,7 @@ mod tests {
cors.inner.validate_allowed_headers(req.head()).unwrap(); cors.inner.validate_allowed_headers(req.head()).unwrap();
} }
#[crate::test] #[ntex_rt::test]
async fn test_validate_origin() { async fn test_validate_origin() {
let mut cors = Cors::new() let mut cors = Cors::new()
.allowed_origin("https://www.example.com") .allowed_origin("https://www.example.com")
@ -995,7 +995,7 @@ mod tests {
assert_eq!(resp.status(), StatusCode::OK); assert_eq!(resp.status(), StatusCode::OK);
} }
#[crate::test] #[ntex_rt::test]
async fn test_no_origin_response() { async fn test_no_origin_response() {
let mut cors = Cors::new() let mut cors = Cors::new()
.disable_preflight() .disable_preflight()
@ -1024,7 +1024,7 @@ mod tests {
); );
} }
#[crate::test] #[ntex_rt::test]
async fn test_response() { async fn test_response() {
let exposed_headers = vec![header::AUTHORIZATION, header::ACCEPT]; let exposed_headers = vec![header::AUTHORIZATION, header::ACCEPT];
let mut cors = Cors::new() let mut cors = Cors::new()
@ -1124,7 +1124,7 @@ mod tests {
assert_eq!("https://www.example.com", origins_str); assert_eq!("https://www.example.com", origins_str);
} }
#[crate::test] #[ntex_rt::test]
async fn test_multiple_origins() { async fn test_multiple_origins() {
let mut cors = Cors::new() let mut cors = Cors::new()
.allowed_origin("https://example.com") .allowed_origin("https://example.com")
@ -1162,7 +1162,7 @@ mod tests {
); );
} }
#[crate::test] #[ntex_rt::test]
async fn test_multiple_origins_preflight() { async fn test_multiple_origins_preflight() {
let mut cors = Cors::new() let mut cors = Cors::new()
.allowed_origin("https://example.com") .allowed_origin("https://example.com")

View file

@ -170,7 +170,7 @@ mod tests {
use crate::web::test::{ok_service, TestRequest}; use crate::web::test::{ok_service, TestRequest};
use crate::web::{DefaultError, Error, HttpResponse}; use crate::web::{DefaultError, Error, HttpResponse};
#[crate::test] #[ntex_rt::test]
async fn test_default_headers() { async fn test_default_headers() {
let mut mw = DefaultHeaders::<DefaultError>::new() let mut mw = DefaultHeaders::<DefaultError>::new()
.header(CONTENT_TYPE, "0001") .header(CONTENT_TYPE, "0001")
@ -198,7 +198,7 @@ mod tests {
assert_eq!(resp.headers().get(CONTENT_TYPE).unwrap(), "0002"); assert_eq!(resp.headers().get(CONTENT_TYPE).unwrap(), "0002");
} }
#[crate::test] #[ntex_rt::test]
async fn test_content_type() { async fn test_content_type() {
let srv = |req: WebRequest<DefaultError>| { let srv = |req: WebRequest<DefaultError>| {
ok::<_, Error>(req.into_response(HttpResponse::Ok().finish())) ok::<_, Error>(req.into_response(HttpResponse::Ok().finish()))

View file

@ -490,7 +490,7 @@ mod tests {
use crate::web::test::TestRequest; use crate::web::test::TestRequest;
use crate::web::{DefaultError, Error}; use crate::web::{DefaultError, Error};
#[crate::test] #[ntex_rt::test]
async fn test_logger() { async fn test_logger() {
let srv = |req: WebRequest<DefaultError>| { let srv = |req: WebRequest<DefaultError>| {
ok::<_, Error>( ok::<_, Error>(
@ -515,7 +515,7 @@ mod tests {
let _res = srv.call(req).await; let _res = srv.call(req).await;
} }
#[crate::test] #[ntex_rt::test]
async fn test_url_path() { async fn test_url_path() {
let mut format = Format::new("%T %U"); let mut format = Format::new("%T %U");
let req = TestRequest::with_header( let req = TestRequest::with_header(
@ -545,7 +545,7 @@ mod tests {
assert!(s.contains("/test/route/yeah")); assert!(s.contains("/test/route/yeah"));
} }
#[crate::test] #[ntex_rt::test]
async fn test_default_format() { async fn test_default_format() {
let mut format = Format::default(); let mut format = Format::default();
@ -578,7 +578,7 @@ mod tests {
assert!(s.contains("ACTIX-WEB")); assert!(s.contains("ACTIX-WEB"));
} }
#[crate::test] #[ntex_rt::test]
async fn test_request_time_format() { async fn test_request_time_format() {
let mut format = Format::new("%t"); let mut format = Format::new("%t");
let req = TestRequest::default().to_srv_request(); let req = TestRequest::default().to_srv_request();

View file

@ -460,7 +460,7 @@ mod tests {
); );
} }
#[crate::test] #[ntex_rt::test]
async fn test_data() { async fn test_data() {
let mut srv = init_service(App::new().app_data(10usize).service( let mut srv = init_service(App::new().app_data(10usize).service(
web::resource("/").to(|req: HttpRequest| { web::resource("/").to(|req: HttpRequest| {
@ -493,7 +493,7 @@ mod tests {
assert_eq!(resp.status(), StatusCode::BAD_REQUEST); assert_eq!(resp.status(), StatusCode::BAD_REQUEST);
} }
#[crate::test] #[ntex_rt::test]
async fn test_extensions_dropped() { async fn test_extensions_dropped() {
struct Tracker { struct Tracker {
dropped: bool, dropped: bool,

View file

@ -558,18 +558,18 @@ impl<Err: ErrorRenderer> ServiceFactory for ResourceEndpoint<Err> {
mod tests { mod tests {
use std::time::Duration; use std::time::Duration;
use actix_rt::time::delay_for;
use futures::future::{ok, ready}; use futures::future::{ok, ready};
use crate::http::header::{self, HeaderValue}; use crate::http::header::{self, HeaderValue};
use crate::http::{Method, StatusCode}; use crate::http::{Method, StatusCode};
use crate::rt::time::delay_for;
use crate::web::middleware::DefaultHeaders; use crate::web::middleware::DefaultHeaders;
use crate::web::service::WebRequest; use crate::web::service::WebRequest;
use crate::web::test::{call_service, init_service, TestRequest}; use crate::web::test::{call_service, init_service, TestRequest};
use crate::web::{self, guard, App, DefaultError, Error, HttpResponse}; use crate::web::{self, guard, App, DefaultError, Error, HttpResponse};
use crate::Service; use crate::Service;
#[crate::test] #[ntex_rt::test]
async fn test_middleware() { async fn test_middleware() {
let mut srv = let mut srv =
init_service( init_service(
@ -593,7 +593,7 @@ mod tests {
); );
} }
#[crate::test] #[ntex_rt::test]
async fn test_middleware_fn() { async fn test_middleware_fn() {
let mut srv = init_service( let mut srv = init_service(
App::new().service( App::new().service(
@ -623,7 +623,7 @@ mod tests {
); );
} }
#[crate::test] #[ntex_rt::test]
async fn test_to() { async fn test_to() {
let mut srv = let mut srv =
init_service(App::new().service(web::resource("/test").to(|| async { init_service(App::new().service(web::resource("/test").to(|| async {
@ -636,7 +636,7 @@ mod tests {
assert_eq!(resp.status(), StatusCode::OK); assert_eq!(resp.status(), StatusCode::OK);
} }
#[crate::test] #[ntex_rt::test]
async fn test_pattern() { async fn test_pattern() {
let mut srv = init_service(App::new().service( let mut srv = init_service(App::new().service(
web::resource(["/test", "/test2"]).to(|| async { HttpResponse::Ok() }), web::resource(["/test", "/test2"]).to(|| async { HttpResponse::Ok() }),
@ -650,7 +650,7 @@ mod tests {
assert_eq!(resp.status(), StatusCode::OK); assert_eq!(resp.status(), StatusCode::OK);
} }
#[crate::test] #[ntex_rt::test]
async fn test_default_resource() { async fn test_default_resource() {
let mut srv = init_service( let mut srv = init_service(
App::new() App::new()
@ -695,7 +695,7 @@ mod tests {
assert_eq!(resp.status(), StatusCode::BAD_REQUEST); assert_eq!(resp.status(), StatusCode::BAD_REQUEST);
} }
#[crate::test] #[ntex_rt::test]
async fn test_resource_guards() { async fn test_resource_guards() {
let mut srv = init_service( let mut srv = init_service(
App::new() App::new()
@ -736,7 +736,7 @@ mod tests {
assert_eq!(resp.status(), StatusCode::NO_CONTENT); assert_eq!(resp.status(), StatusCode::NO_CONTENT);
} }
#[crate::test] #[ntex_rt::test]
async fn test_data() { async fn test_data() {
let mut srv = init_service( let mut srv = init_service(
App::new() App::new()

View file

@ -485,7 +485,7 @@ pub(crate) mod tests {
responder responder
} }
#[crate::test] #[ntex_rt::test]
async fn test_option_responder() { async fn test_option_responder() {
let mut srv = init_service( let mut srv = init_service(
web::App::new() web::App::new()
@ -512,7 +512,7 @@ pub(crate) mod tests {
} }
} }
#[crate::test] #[ntex_rt::test]
async fn test_responder() { async fn test_responder() {
let req = TestRequest::default().to_http_request(); let req = TestRequest::default().to_http_request();
@ -585,7 +585,7 @@ pub(crate) mod tests {
assert_eq!(resp.status(), StatusCode::BAD_REQUEST); assert_eq!(resp.status(), StatusCode::BAD_REQUEST);
} }
#[crate::test] #[ntex_rt::test]
async fn test_result_responder() { async fn test_result_responder() {
let req = TestRequest::default().to_http_request(); let req = TestRequest::default().to_http_request();
@ -612,7 +612,7 @@ pub(crate) mod tests {
assert!(res.is_err()); assert!(res.is_err());
} }
#[crate::test] #[ntex_rt::test]
async fn test_custom_responder() { async fn test_custom_responder() {
let req = TestRequest::default().to_http_request(); let req = TestRequest::default().to_http_request();
let res = responder("test".to_string()) let res = responder("test".to_string())
@ -637,7 +637,7 @@ pub(crate) mod tests {
); );
} }
#[crate::test] #[ntex_rt::test]
async fn test_tuple_responder_with_status_code() { async fn test_tuple_responder_with_status_code() {
let req = TestRequest::default().to_http_request(); let req = TestRequest::default().to_http_request();
let res = Responder::<DefaultError>::respond_to( let res = Responder::<DefaultError>::respond_to(

View file

@ -206,11 +206,11 @@ impl<Err: ErrorRenderer> Route<Err> {
mod tests { mod tests {
use std::time::Duration; use std::time::Duration;
use actix_rt::time::delay_for;
use bytes::Bytes; use bytes::Bytes;
use serde_derive::Serialize; use serde_derive::Serialize;
use crate::http::{Method, StatusCode}; use crate::http::{Method, StatusCode};
use crate::rt::time::delay_for;
use crate::web::test::{call_service, init_service, read_body, TestRequest}; use crate::web::test::{call_service, init_service, read_body, TestRequest};
use crate::web::{self, error, App, DefaultError, HttpResponse}; use crate::web::{self, error, App, DefaultError, HttpResponse};
@ -219,7 +219,7 @@ mod tests {
name: String, name: String,
} }
#[crate::test] #[ntex_rt::test]
async fn test_route() { async fn test_route() {
let mut srv = init_service( let mut srv = init_service(
App::new() App::new()

View file

@ -689,7 +689,7 @@ mod tests {
use crate::web::DefaultError; use crate::web::DefaultError;
use crate::web::{self, guard, App, HttpRequest, HttpResponse}; use crate::web::{self, guard, App, HttpRequest, HttpResponse};
#[crate::test] #[ntex_rt::test]
async fn test_scope() { async fn test_scope() {
let mut srv = let mut srv =
init_service(App::new().service( init_service(App::new().service(
@ -704,7 +704,7 @@ mod tests {
assert_eq!(resp.status(), StatusCode::OK); assert_eq!(resp.status(), StatusCode::OK);
} }
#[crate::test] #[ntex_rt::test]
async fn test_scope_root() { async fn test_scope_root() {
let mut srv = init_service( let mut srv = init_service(
App::new().service( App::new().service(
@ -726,7 +726,7 @@ mod tests {
assert_eq!(resp.status(), StatusCode::CREATED); assert_eq!(resp.status(), StatusCode::CREATED);
} }
#[crate::test] #[ntex_rt::test]
async fn test_scope_root2() { async fn test_scope_root2() {
let mut srv = init_service( let mut srv = init_service(
App::new().service( App::new().service(
@ -745,7 +745,7 @@ mod tests {
assert_eq!(resp.status(), StatusCode::OK); assert_eq!(resp.status(), StatusCode::OK);
} }
#[crate::test] #[ntex_rt::test]
async fn test_scope_root3() { async fn test_scope_root3() {
let mut srv = init_service( let mut srv = init_service(
App::new().service( App::new().service(
@ -764,7 +764,7 @@ mod tests {
assert_eq!(resp.status(), StatusCode::OK); assert_eq!(resp.status(), StatusCode::OK);
} }
#[crate::test] #[ntex_rt::test]
async fn test_scope_route() { async fn test_scope_route() {
let mut srv = init_service( let mut srv = init_service(
App::new().service( App::new().service(
@ -792,7 +792,7 @@ mod tests {
assert_eq!(resp.status(), StatusCode::NOT_FOUND); assert_eq!(resp.status(), StatusCode::NOT_FOUND);
} }
#[crate::test] #[ntex_rt::test]
async fn test_scope_route_without_leading_slash() { async fn test_scope_route_without_leading_slash() {
let mut srv = init_service( let mut srv = init_service(
App::new().service( App::new().service(
@ -822,7 +822,7 @@ mod tests {
assert_eq!(resp.status(), StatusCode::METHOD_NOT_ALLOWED); assert_eq!(resp.status(), StatusCode::METHOD_NOT_ALLOWED);
} }
#[crate::test] #[ntex_rt::test]
async fn test_scope_guard() { async fn test_scope_guard() {
let mut srv = let mut srv =
init_service(App::new().service( init_service(App::new().service(
@ -845,7 +845,7 @@ mod tests {
assert_eq!(resp.status(), StatusCode::OK); assert_eq!(resp.status(), StatusCode::OK);
} }
#[crate::test] #[ntex_rt::test]
async fn test_scope_variable_segment() { async fn test_scope_variable_segment() {
let mut srv = let mut srv =
init_service(App::new().service(web::scope("/ab-{project}").service( init_service(App::new().service(web::scope("/ab-{project}").service(
@ -873,7 +873,7 @@ mod tests {
assert_eq!(resp.status(), StatusCode::NOT_FOUND); assert_eq!(resp.status(), StatusCode::NOT_FOUND);
} }
#[crate::test] #[ntex_rt::test]
async fn test_nested_scope() { async fn test_nested_scope() {
let mut srv = init_service(App::new().service(web::scope("/app").service( let mut srv = init_service(App::new().service(web::scope("/app").service(
web::scope("/t1").service( web::scope("/t1").service(
@ -887,7 +887,7 @@ mod tests {
assert_eq!(resp.status(), StatusCode::CREATED); assert_eq!(resp.status(), StatusCode::CREATED);
} }
#[crate::test] #[ntex_rt::test]
async fn test_nested_scope_no_slash() { async fn test_nested_scope_no_slash() {
let mut srv = init_service(App::new().service(web::scope("/app").service( let mut srv = init_service(App::new().service(web::scope("/app").service(
web::scope("t1").service( web::scope("t1").service(
@ -901,7 +901,7 @@ mod tests {
assert_eq!(resp.status(), StatusCode::CREATED); assert_eq!(resp.status(), StatusCode::CREATED);
} }
#[crate::test] #[ntex_rt::test]
async fn test_nested_scope_root() { async fn test_nested_scope_root() {
let mut srv = init_service( let mut srv = init_service(
App::new().service( App::new().service(
@ -925,7 +925,7 @@ mod tests {
assert_eq!(resp.status(), StatusCode::CREATED); assert_eq!(resp.status(), StatusCode::CREATED);
} }
#[crate::test] #[ntex_rt::test]
async fn test_nested_scope_filter() { async fn test_nested_scope_filter() {
let mut srv = let mut srv =
init_service(App::new().service(web::scope("/app").service( init_service(App::new().service(web::scope("/app").service(
@ -948,7 +948,7 @@ mod tests {
assert_eq!(resp.status(), StatusCode::OK); assert_eq!(resp.status(), StatusCode::OK);
} }
#[crate::test] #[ntex_rt::test]
async fn test_nested_scope_with_variable_segment() { async fn test_nested_scope_with_variable_segment() {
let mut srv = init_service(App::new().service(web::scope("/app").service( let mut srv = init_service(App::new().service(web::scope("/app").service(
web::scope("/{project_id}").service(web::resource("/path1").to( web::scope("/{project_id}").service(web::resource("/path1").to(
@ -973,7 +973,7 @@ mod tests {
} }
} }
#[crate::test] #[ntex_rt::test]
async fn test_nested2_scope_with_variable_segment() { async fn test_nested2_scope_with_variable_segment() {
let mut srv = init_service(App::new().service(web::scope("/app").service( let mut srv = init_service(App::new().service(web::scope("/app").service(
web::scope("/{project}").service(web::scope("/{id}").service( web::scope("/{project}").service(web::scope("/{id}").service(
@ -1005,7 +1005,7 @@ mod tests {
assert_eq!(resp.status(), StatusCode::NOT_FOUND); assert_eq!(resp.status(), StatusCode::NOT_FOUND);
} }
#[crate::test] #[ntex_rt::test]
async fn test_default_resource() { async fn test_default_resource() {
let mut srv = init_service( let mut srv = init_service(
App::new().service( App::new().service(
@ -1027,7 +1027,7 @@ mod tests {
assert_eq!(resp.status(), StatusCode::NOT_FOUND); assert_eq!(resp.status(), StatusCode::NOT_FOUND);
} }
#[crate::test] #[ntex_rt::test]
async fn test_default_resource_propagation() { async fn test_default_resource_propagation() {
let mut srv = init_service( let mut srv = init_service(
App::new() App::new()
@ -1054,7 +1054,7 @@ mod tests {
assert_eq!(resp.status(), StatusCode::METHOD_NOT_ALLOWED); assert_eq!(resp.status(), StatusCode::METHOD_NOT_ALLOWED);
} }
#[crate::test] #[ntex_rt::test]
async fn test_middleware() { async fn test_middleware() {
let mut srv = init_service( let mut srv = init_service(
App::new().service( App::new().service(
@ -1080,7 +1080,7 @@ mod tests {
); );
} }
#[crate::test] #[ntex_rt::test]
async fn test_middleware_fn() { async fn test_middleware_fn() {
let mut srv = init_service( let mut srv = init_service(
App::new().service( App::new().service(
@ -1108,7 +1108,7 @@ mod tests {
); );
} }
#[crate::test] #[ntex_rt::test]
async fn test_override_data() { async fn test_override_data() {
let mut srv = init_service(App::new().data(1usize).service( let mut srv = init_service(App::new().data(1usize).service(
web::scope("app").data(10usize).route( web::scope("app").data(10usize).route(
@ -1127,7 +1127,7 @@ mod tests {
assert_eq!(resp.status(), StatusCode::OK); assert_eq!(resp.status(), StatusCode::OK);
} }
#[crate::test] #[ntex_rt::test]
async fn test_override_app_data() { async fn test_override_app_data() {
let mut srv = init_service(App::new().app_data(web::Data::new(1usize)).service( let mut srv = init_service(App::new().app_data(web::Data::new(1usize)).service(
web::scope("app").app_data(web::Data::new(10usize)).route( web::scope("app").app_data(web::Data::new(10usize)).route(
@ -1146,7 +1146,7 @@ mod tests {
assert_eq!(resp.status(), StatusCode::OK); assert_eq!(resp.status(), StatusCode::OK);
} }
#[crate::test] #[ntex_rt::test]
async fn test_scope_config() { async fn test_scope_config() {
let mut srv = let mut srv =
init_service(App::new().service(web::scope("/app").configure(|s| { init_service(App::new().service(web::scope("/app").configure(|s| {
@ -1159,7 +1159,7 @@ mod tests {
assert_eq!(resp.status(), StatusCode::OK); assert_eq!(resp.status(), StatusCode::OK);
} }
#[crate::test] #[ntex_rt::test]
async fn test_scope_config_2() { async fn test_scope_config_2() {
let mut srv = let mut srv =
init_service(App::new().service(web::scope("/app").configure(|s| { init_service(App::new().service(web::scope("/app").configure(|s| {
@ -1174,7 +1174,7 @@ mod tests {
assert_eq!(resp.status(), StatusCode::OK); assert_eq!(resp.status(), StatusCode::OK);
} }
#[crate::test] #[ntex_rt::test]
async fn test_url_for_external() { async fn test_url_for_external() {
let mut srv = let mut srv =
init_service(App::new().service(web::scope("/app").configure(|s| { init_service(App::new().service(web::scope("/app").configure(|s| {
@ -1203,7 +1203,7 @@ mod tests {
assert_eq!(body, &b"https://youtube.com/watch/xxxxxx"[..]); assert_eq!(body, &b"https://youtube.com/watch/xxxxxx"[..]);
} }
#[crate::test] #[ntex_rt::test]
async fn test_url_for_nested() { async fn test_url_for_nested() {
let mut srv = init_service(App::new().service(web::scope("/a").service( let mut srv = init_service(App::new().service(web::scope("/a").service(
web::scope("/b").service(web::resource("/c/{stuff}").name("c").route( web::scope("/b").service(web::resource("/c/{stuff}").name("c").route(

View file

@ -450,7 +450,7 @@ where
mut self, mut self,
lst: std::os::unix::net::UnixListener, lst: std::os::unix::net::UnixListener,
) -> io::Result<Self> { ) -> io::Result<Self> {
use actix_rt::net::UnixStream; use crate::rt::net::UnixStream;
let cfg = self.config.clone(); let cfg = self.config.clone();
let factory = self.factory.clone(); let factory = self.factory.clone();
@ -490,7 +490,7 @@ where
where where
A: AsRef<std::path::Path>, A: AsRef<std::path::Path>,
{ {
use actix_rt::net::UnixStream; use crate::rt::net::UnixStream;
let cfg = self.config.clone(); let cfg = self.config.clone();
let factory = self.factory.clone(); let factory = self.factory.clone();

View file

@ -600,7 +600,7 @@ mod tests {
assert!(WebRequest::<DefaultError>::from_request(r).is_err()); assert!(WebRequest::<DefaultError>::from_request(r).is_err());
} }
#[crate::test] #[ntex_rt::test]
async fn test_service() { async fn test_service() {
let mut srv = init_service(App::new().service( let mut srv = init_service(App::new().service(
web::service("/test").name("test").finish( web::service("/test").name("test").finish(

View file

@ -278,7 +278,7 @@ where
/// ///
/// For unit testing, actix provides a request builder type and a simple handler runner. TestRequest implements a builder-like pattern. /// For unit testing, actix provides a request builder type and a simple handler runner. TestRequest implements a builder-like pattern.
/// You can generate various types of request via TestRequest's methods: /// You can generate various types of request via TestRequest's methods:
/// * `TestRequest::to_request` creates `actix_http::Request` instance. /// * `TestRequest::to_request` creates `ntex::http::Request` instance.
/// * `TestRequest::to_srv_request` creates `WebRequest` instance, which is used for testing middlewares and chain adapters. /// * `TestRequest::to_srv_request` creates `WebRequest` instance, which is used for testing middlewares and chain adapters.
/// * `TestRequest::to_srv_response` creates `WebResponse` instance. /// * `TestRequest::to_srv_response` creates `WebResponse` instance.
/// * `TestRequest::to_http_request` creates `HttpRequest` instance, which is used for testing handlers. /// * `TestRequest::to_http_request` creates `HttpRequest` instance, which is used for testing handlers.
@ -615,98 +615,102 @@ where
// run server in separate thread // run server in separate thread
thread::spawn(move || { thread::spawn(move || {
let sys = System::new("actix-test-server"); let mut sys = System::new("actix-test-server");
let cfg = cfg.clone();
let factory = factory.clone();
let ctimeout = cfg.client_timeout;
let tcp = net::TcpListener::bind("127.0.0.1:0").unwrap(); let tcp = net::TcpListener::bind("127.0.0.1:0").unwrap();
let local_addr = tcp.local_addr().unwrap(); let local_addr = tcp.local_addr().unwrap();
let factory = factory.clone();
let cfg = cfg.clone();
let ctimeout = cfg.client_timeout;
let builder = Server::build().workers(1).disable_signals();
let srv = match cfg.stream { let srv = sys.exec(|| {
StreamType::Tcp => match cfg.tp { let builder = Server::build().workers(1).disable_signals();
HttpVer::Http1 => builder.listen("test", tcp, move || {
let cfg = match cfg.stream {
AppConfig::new(false, local_addr, format!("{}", local_addr)); StreamType::Tcp => match cfg.tp {
HttpService::build() HttpVer::Http1 => builder.listen("test", tcp, move || {
.client_timeout(ctimeout) let cfg =
.h1(map_config(factory(), move |_| cfg.clone())) AppConfig::new(false, local_addr, format!("{}", local_addr));
.tcp() HttpService::build()
}), .client_timeout(ctimeout)
HttpVer::Http2 => builder.listen("test", tcp, move || { .h1(map_config(factory(), move |_| cfg.clone()))
let cfg = .tcp()
AppConfig::new(false, local_addr, format!("{}", local_addr)); }),
HttpService::build() HttpVer::Http2 => builder.listen("test", tcp, move || {
.client_timeout(ctimeout) let cfg =
.h2(map_config(factory(), move |_| cfg.clone())) AppConfig::new(false, local_addr, format!("{}", local_addr));
.tcp() HttpService::build()
}), .client_timeout(ctimeout)
HttpVer::Both => builder.listen("test", tcp, move || { .h2(map_config(factory(), move |_| cfg.clone()))
let cfg = .tcp()
AppConfig::new(false, local_addr, format!("{}", local_addr)); }),
HttpService::build() HttpVer::Both => builder.listen("test", tcp, move || {
.client_timeout(ctimeout) let cfg =
.finish(map_config(factory(), move |_| cfg.clone())) AppConfig::new(false, local_addr, format!("{}", local_addr));
.tcp() HttpService::build()
}), .client_timeout(ctimeout)
}, .finish(map_config(factory(), move |_| cfg.clone()))
#[cfg(feature = "openssl")] .tcp()
StreamType::Openssl(acceptor) => match cfg.tp { }),
HttpVer::Http1 => builder.listen("test", tcp, move || { },
let cfg = #[cfg(feature = "openssl")]
AppConfig::new(true, local_addr, format!("{}", local_addr)); StreamType::Openssl(acceptor) => match cfg.tp {
HttpService::build() HttpVer::Http1 => builder.listen("test", tcp, move || {
.client_timeout(ctimeout) let cfg =
.h1(map_config(factory(), move |_| cfg.clone())) AppConfig::new(true, local_addr, format!("{}", local_addr));
.openssl(acceptor.clone()) HttpService::build()
}), .client_timeout(ctimeout)
HttpVer::Http2 => builder.listen("test", tcp, move || { .h1(map_config(factory(), move |_| cfg.clone()))
let cfg = .openssl(acceptor.clone())
AppConfig::new(true, local_addr, format!("{}", local_addr)); }),
HttpService::build() HttpVer::Http2 => builder.listen("test", tcp, move || {
.client_timeout(ctimeout) let cfg =
.h2(map_config(factory(), move |_| cfg.clone())) AppConfig::new(true, local_addr, format!("{}", local_addr));
.openssl(acceptor.clone()) HttpService::build()
}), .client_timeout(ctimeout)
HttpVer::Both => builder.listen("test", tcp, move || { .h2(map_config(factory(), move |_| cfg.clone()))
let cfg = .openssl(acceptor.clone())
AppConfig::new(true, local_addr, format!("{}", local_addr)); }),
HttpService::build() HttpVer::Both => builder.listen("test", tcp, move || {
.client_timeout(ctimeout) let cfg =
.finish(map_config(factory(), move |_| cfg.clone())) AppConfig::new(true, local_addr, format!("{}", local_addr));
.openssl(acceptor.clone()) HttpService::build()
}), .client_timeout(ctimeout)
}, .finish(map_config(factory(), move |_| cfg.clone()))
#[cfg(feature = "rustls")] .openssl(acceptor.clone())
StreamType::Rustls(config) => match cfg.tp { }),
HttpVer::Http1 => builder.listen("test", tcp, move || { },
let cfg = #[cfg(feature = "rustls")]
AppConfig::new(true, local_addr, format!("{}", local_addr)); StreamType::Rustls(config) => match cfg.tp {
HttpService::build() HttpVer::Http1 => builder.listen("test", tcp, move || {
.client_timeout(ctimeout) let cfg =
.h1(map_config(factory(), move |_| cfg.clone())) AppConfig::new(true, local_addr, format!("{}", local_addr));
.rustls(config.clone()) HttpService::build()
}), .client_timeout(ctimeout)
HttpVer::Http2 => builder.listen("test", tcp, move || { .h1(map_config(factory(), move |_| cfg.clone()))
let cfg = .rustls(config.clone())
AppConfig::new(true, local_addr, format!("{}", local_addr)); }),
HttpService::build() HttpVer::Http2 => builder.listen("test", tcp, move || {
.client_timeout(ctimeout) let cfg =
.h2(map_config(factory(), move |_| cfg.clone())) AppConfig::new(true, local_addr, format!("{}", local_addr));
.rustls(config.clone()) HttpService::build()
}), .client_timeout(ctimeout)
HttpVer::Both => builder.listen("test", tcp, move || { .h2(map_config(factory(), move |_| cfg.clone()))
let cfg = .rustls(config.clone())
AppConfig::new(true, local_addr, format!("{}", local_addr)); }),
HttpService::build() HttpVer::Both => builder.listen("test", tcp, move || {
.client_timeout(ctimeout) let cfg =
.finish(map_config(factory(), move |_| cfg.clone())) AppConfig::new(true, local_addr, format!("{}", local_addr));
.rustls(config.clone()) HttpService::build()
}), .client_timeout(ctimeout)
}, .finish(map_config(factory(), move |_| cfg.clone()))
} .rustls(config.clone())
.unwrap() }),
.start(); },
}
.unwrap()
.start()
});
tx.send((System::current(), srv, local_addr)).unwrap(); tx.send((System::current(), srv, local_addr)).unwrap();
sys.run() sys.run()
@ -843,7 +847,7 @@ pub fn unused_addr() -> net::SocketAddr {
pub struct TestServer { pub struct TestServer {
addr: net::SocketAddr, addr: net::SocketAddr,
client: Client, client: Client,
system: actix_rt::System, system: crate::rt::System,
ssl: bool, ssl: bool,
server: Server, server: Server,
} }
@ -957,7 +961,7 @@ mod tests {
use crate::http::HttpMessage; use crate::http::HttpMessage;
use crate::web::{self, App, Data, Error, HttpResponse}; use crate::web::{self, App, Data, Error, HttpResponse};
#[crate::test] #[ntex_rt::test]
async fn test_basics() { async fn test_basics() {
let req = TestRequest::with_header(header::CONTENT_TYPE, "application/json") let req = TestRequest::with_header(header::CONTENT_TYPE, "application/json")
.version(Version::HTTP_2) .version(Version::HTTP_2)
@ -978,7 +982,7 @@ mod tests {
assert_eq!(*data.get_ref(), 20); assert_eq!(*data.get_ref(), 20);
} }
#[crate::test] #[ntex_rt::test]
async fn test_request_methods() { async fn test_request_methods() {
let mut app = init_service( let mut app = init_service(
App::new().service( App::new().service(
@ -1016,7 +1020,7 @@ mod tests {
assert_eq!(result, Bytes::from_static(b"delete!")); assert_eq!(result, Bytes::from_static(b"delete!"));
} }
#[crate::test] #[ntex_rt::test]
async fn test_response() { async fn test_response() {
let mut app = let mut app =
init_service(App::new().service(web::resource("/index.html").route( init_service(App::new().service(web::resource("/index.html").route(
@ -1039,7 +1043,7 @@ mod tests {
name: String, name: String,
} }
#[crate::test] #[ntex_rt::test]
async fn test_response_json() { async fn test_response_json() {
let mut app = init_service(App::new().service(web::resource("/people").route( let mut app = init_service(App::new().service(web::resource("/people").route(
web::post().to(|person: web::types::Json<Person>| async { web::post().to(|person: web::types::Json<Person>| async {
@ -1060,7 +1064,7 @@ mod tests {
assert_eq!(&result.id, "12345"); assert_eq!(&result.id, "12345");
} }
#[crate::test] #[ntex_rt::test]
async fn test_request_response_form() { async fn test_request_response_form() {
let mut app = init_service(App::new().service(web::resource("/people").route( let mut app = init_service(App::new().service(web::resource("/people").route(
web::post().to(|person: web::types::Form<Person>| async { web::post().to(|person: web::types::Form<Person>| async {
@ -1086,7 +1090,7 @@ mod tests {
assert_eq!(&result.name, "User name"); assert_eq!(&result.name, "User name");
} }
#[crate::test] #[ntex_rt::test]
async fn test_request_response_json() { async fn test_request_response_json() {
let mut app = init_service(App::new().service(web::resource("/people").route( let mut app = init_service(App::new().service(web::resource("/people").route(
web::post().to(|person: web::types::Json<Person>| async { web::post().to(|person: web::types::Json<Person>| async {
@ -1112,7 +1116,7 @@ mod tests {
assert_eq!(&result.name, "User name"); assert_eq!(&result.name, "User name");
} }
#[crate::test] #[ntex_rt::test]
async fn test_async_with_block() { async fn test_async_with_block() {
async fn async_with_block() -> Result<HttpResponse, Error> { async fn async_with_block() -> Result<HttpResponse, Error> {
let res = web::block(move || Some(4usize).ok_or("wrong")).await; let res = web::block(move || Some(4usize).ok_or("wrong")).await;
@ -1138,7 +1142,7 @@ mod tests {
assert!(res.status().is_success()); assert!(res.status().is_success());
} }
#[crate::test] #[ntex_rt::test]
async fn test_server_data() { async fn test_server_data() {
async fn handler(data: web::Data<usize>) -> crate::http::ResponseBuilder { async fn handler(data: web::Data<usize>) -> crate::http::ResponseBuilder {
assert_eq!(**data, 10); assert_eq!(**data, 10);

View file

@ -362,7 +362,7 @@ where
// counter: i64, // counter: i64,
// } // }
// #[crate::test] // #[ntex_rt::test]
// async fn test_form() { // async fn test_form() {
// let (req, mut pl) = // let (req, mut pl) =
// TestRequest::with_header(CONTENT_TYPE, "application/x-www-form-urlencoded") // TestRequest::with_header(CONTENT_TYPE, "application/x-www-form-urlencoded")
@ -398,7 +398,7 @@ where
// } // }
// } // }
// #[crate::test] // #[ntex_rt::test]
// async fn test_urlencoded_error() { // async fn test_urlencoded_error() {
// let (req, mut pl) = // let (req, mut pl) =
// TestRequest::with_header(CONTENT_TYPE, "application/x-www-form-urlencoded") // TestRequest::with_header(CONTENT_TYPE, "application/x-www-form-urlencoded")
@ -424,7 +424,7 @@ where
// assert!(eq(info.err().unwrap(), UrlencodedError::ContentType)); // assert!(eq(info.err().unwrap(), UrlencodedError::ContentType));
// } // }
// #[crate::test] // #[ntex_rt::test]
// async fn test_urlencoded() { // async fn test_urlencoded() {
// let (req, mut pl) = // let (req, mut pl) =
// TestRequest::with_header(CONTENT_TYPE, "application/x-www-form-urlencoded") // TestRequest::with_header(CONTENT_TYPE, "application/x-www-form-urlencoded")
@ -459,7 +459,7 @@ where
// ); // );
// } // }
// #[crate::test] // #[ntex_rt::test]
// async fn test_responder() { // async fn test_responder() {
// let req = TestRequest::default().to_http_request(); // let req = TestRequest::default().to_http_request();

View file

@ -414,7 +414,7 @@ where
// } // }
// } // }
// #[crate::test] // #[ntex_rt::test]
// async fn test_responder() { // async fn test_responder() {
// let req = TestRequest::default().to_http_request(); // let req = TestRequest::default().to_http_request();
@ -431,7 +431,7 @@ where
// assert_eq!(resp.body().bin_ref(), b"{\"name\":\"test\"}"); // assert_eq!(resp.body().bin_ref(), b"{\"name\":\"test\"}");
// } // }
// #[crate::test] // #[ntex_rt::test]
// async fn test_custom_error_responder() { // async fn test_custom_error_responder() {
// let (req, mut pl) = TestRequest::default() // let (req, mut pl) = TestRequest::default()
// .header( // .header(
@ -462,7 +462,7 @@ where
// assert_eq!(msg.name, "invalid request"); // assert_eq!(msg.name, "invalid request");
// } // }
// #[crate::test] // #[ntex_rt::test]
// async fn test_extract() { // async fn test_extract() {
// let (req, mut pl) = TestRequest::default() // let (req, mut pl) = TestRequest::default()
// .header( // .header(
@ -522,7 +522,7 @@ where
// assert!(format!("{}", s.err().unwrap()).contains("Content type error")); // assert!(format!("{}", s.err().unwrap()).contains("Content type error"));
// } // }
// #[crate::test] // #[ntex_rt::test]
// async fn test_json_body() { // async fn test_json_body() {
// let (req, mut pl) = TestRequest::default().to_http_parts(); // let (req, mut pl) = TestRequest::default().to_http_parts();
// let json = JsonBody::<MyObject>::new(&req, &mut pl, None).await; // let json = JsonBody::<MyObject>::new(&req, &mut pl, None).await;
@ -574,7 +574,7 @@ where
// ); // );
// } // }
// #[crate::test] // #[ntex_rt::test]
// async fn test_with_json_and_bad_content_type() { // async fn test_with_json_and_bad_content_type() {
// let (req, mut pl) = TestRequest::with_header( // let (req, mut pl) = TestRequest::with_header(
// header::CONTENT_TYPE, // header::CONTENT_TYPE,
@ -592,7 +592,7 @@ where
// assert!(s.is_err()) // assert!(s.is_err())
// } // }
// #[crate::test] // #[ntex_rt::test]
// async fn test_with_json_and_good_custom_content_type() { // async fn test_with_json_and_good_custom_content_type() {
// let (req, mut pl) = TestRequest::with_header( // let (req, mut pl) = TestRequest::with_header(
// header::CONTENT_TYPE, // header::CONTENT_TYPE,
@ -612,7 +612,7 @@ where
// assert!(s.is_ok()) // assert!(s.is_ok())
// } // }
// #[crate::test] // #[ntex_rt::test]
// async fn test_with_json_and_bad_custom_content_type() { // async fn test_with_json_and_bad_custom_content_type() {
// let (req, mut pl) = TestRequest::with_header( // let (req, mut pl) = TestRequest::with_header(
// header::CONTENT_TYPE, // header::CONTENT_TYPE,

View file

@ -202,7 +202,7 @@ where
// value: u32, // value: u32,
// } // }
// #[crate::test] // #[ntex_rt::test]
// async fn test_extract_path_single() { // async fn test_extract_path_single() {
// let resource = ResourceDef::new("/{value}/"); // let resource = ResourceDef::new("/{value}/");
@ -214,7 +214,7 @@ where
// assert!(Path::<MyStruct>::from_request(&req, &mut pl).await.is_err()); // assert!(Path::<MyStruct>::from_request(&req, &mut pl).await.is_err());
// } // }
// #[crate::test] // #[ntex_rt::test]
// async fn test_tuple_extract() { // async fn test_tuple_extract() {
// let resource = ResourceDef::new("/{key}/{value}/"); // let resource = ResourceDef::new("/{key}/{value}/");
@ -241,7 +241,7 @@ where
// let () = <()>::from_request(&req, &mut pl).await.unwrap(); // let () = <()>::from_request(&req, &mut pl).await.unwrap();
// } // }
// #[crate::test] // #[ntex_rt::test]
// async fn test_request_extract() { // async fn test_request_extract() {
// let mut req = TestRequest::with_uri("/name/user1/?id=test").to_srv_request(); // let mut req = TestRequest::with_uri("/name/user1/?id=test").to_srv_request();
@ -289,7 +289,7 @@ where
// assert_eq!(res[1], "32".to_owned()); // assert_eq!(res[1], "32".to_owned());
// } // }
// #[crate::test] // #[ntex_rt::test]
// async fn test_custom_err_handler() { // async fn test_custom_err_handler() {
// let (req, mut pl) = TestRequest::with_uri("/name/user1/") // let (req, mut pl) = TestRequest::with_uri("/name/user1/")
// .data(PathConfig::default().error_handler(|err, _| { // .data(PathConfig::default().error_handler(|err, _| {

View file

@ -422,7 +422,7 @@ impl Future for HttpMessageBody {
// use crate::http::header; // use crate::http::header;
// use crate::web::test::TestRequest; // use crate::web::test::TestRequest;
// #[crate::test] // #[ntex_rt::test]
// async fn test_payload_config() { // async fn test_payload_config() {
// let req = TestRequest::default().to_http_request(); // let req = TestRequest::default().to_http_request();
// let cfg = PayloadConfig::default().mimetype(mime::APPLICATION_JSON); // let cfg = PayloadConfig::default().mimetype(mime::APPLICATION_JSON);
@ -440,7 +440,7 @@ impl Future for HttpMessageBody {
// assert!(cfg.check_mimetype(&req).is_ok()); // assert!(cfg.check_mimetype(&req).is_ok());
// } // }
// #[crate::test] // #[ntex_rt::test]
// async fn test_bytes() { // async fn test_bytes() {
// let (req, mut pl) = TestRequest::with_header(header::CONTENT_LENGTH, "11") // let (req, mut pl) = TestRequest::with_header(header::CONTENT_LENGTH, "11")
// .set_payload(Bytes::from_static(b"hello=world")) // .set_payload(Bytes::from_static(b"hello=world"))
@ -450,7 +450,7 @@ impl Future for HttpMessageBody {
// assert_eq!(s, Bytes::from_static(b"hello=world")); // assert_eq!(s, Bytes::from_static(b"hello=world"));
// } // }
// #[crate::test] // #[ntex_rt::test]
// async fn test_string() { // async fn test_string() {
// let (req, mut pl) = TestRequest::with_header(header::CONTENT_LENGTH, "11") // let (req, mut pl) = TestRequest::with_header(header::CONTENT_LENGTH, "11")
// .set_payload(Bytes::from_static(b"hello=world")) // .set_payload(Bytes::from_static(b"hello=world"))
@ -460,7 +460,7 @@ impl Future for HttpMessageBody {
// assert_eq!(s, "hello=world"); // assert_eq!(s, "hello=world");
// } // }
// #[crate::test] // #[ntex_rt::test]
// async fn test_message_body() { // async fn test_message_body() {
// let (req, mut pl) = TestRequest::with_header(header::CONTENT_LENGTH, "xxxx") // let (req, mut pl) = TestRequest::with_header(header::CONTENT_LENGTH, "xxxx")
// .to_srv_request() // .to_srv_request()

View file

@ -169,7 +169,7 @@ where
// id: String, // id: String,
// } // }
// #[crate::test] // #[ntex_rt::test]
// async fn test_service_request_extract() { // async fn test_service_request_extract() {
// let req = TestRequest::with_uri("/name/user1/").to_srv_request(); // let req = TestRequest::with_uri("/name/user1/").to_srv_request();
// assert!(Query::<Id>::from_query(&req.query_string()).is_err()); // assert!(Query::<Id>::from_query(&req.query_string()).is_err());
@ -185,7 +185,7 @@ where
// assert_eq!(s.id, "test1"); // assert_eq!(s.id, "test1");
// } // }
// #[crate::test] // #[ntex_rt::test]
// async fn test_request_extract() { // async fn test_request_extract() {
// let req = TestRequest::with_uri("/name/user1/").to_srv_request(); // let req = TestRequest::with_uri("/name/user1/").to_srv_request();
// let (req, mut pl) = req.into_parts(); // let (req, mut pl) = req.into_parts();

View file

@ -28,13 +28,15 @@ fn test_bind() {
let (tx, rx) = mpsc::channel(); let (tx, rx) = mpsc::channel();
let h = thread::spawn(move || { let h = thread::spawn(move || {
let sys = ntex::rt::System::new("test"); let mut sys = ntex::rt::System::new("test");
let srv = Server::build() let srv = sys.exec(|| {
.workers(1) Server::build()
.disable_signals() .workers(1)
.bind("test", addr, move || fn_service(|_| ok::<_, ()>(()))) .disable_signals()
.unwrap() .bind("test", addr, move || fn_service(|_| ok::<_, ()>(())))
.start(); .unwrap()
.start()
});
let _ = tx.send((srv, ntex::rt::System::current())); let _ = tx.send((srv, ntex::rt::System::current()));
let _ = sys.run(); let _ = sys.run();
}); });
@ -52,14 +54,16 @@ fn test_listen() {
let (tx, rx) = mpsc::channel(); let (tx, rx) = mpsc::channel();
let h = thread::spawn(move || { let h = thread::spawn(move || {
let sys = ntex::rt::System::new("test"); let mut sys = ntex::rt::System::new("test");
let lst = net::TcpListener::bind(addr).unwrap(); let lst = net::TcpListener::bind(addr).unwrap();
Server::build() sys.exec(|| {
.disable_signals() Server::build()
.workers(1) .disable_signals()
.listen("test", lst, move || fn_service(|_| ok::<_, ()>(()))) .workers(1)
.unwrap() .listen("test", lst, move || fn_service(|_| ok::<_, ()>(())))
.start(); .unwrap()
.start()
});
let _ = tx.send(ntex::rt::System::current()); let _ = tx.send(ntex::rt::System::current());
let _ = sys.run(); let _ = sys.run();
}); });
@ -78,19 +82,21 @@ fn test_start() {
let (tx, rx) = mpsc::channel(); let (tx, rx) = mpsc::channel();
let h = thread::spawn(move || { let h = thread::spawn(move || {
let sys = ntex::rt::System::new("test"); let mut sys = ntex::rt::System::new("test");
let srv: Server = Server::build() let srv = sys.exec(|| {
.backlog(100) Server::build()
.disable_signals() .backlog(100)
.bind("test", addr, move || { .disable_signals()
fn_service(|io: TcpStream| async move { .bind("test", addr, move || {
let mut f = Framed::new(io, BytesCodec); fn_service(|io: TcpStream| async move {
f.send(Bytes::from_static(b"test")).await.unwrap(); let mut f = Framed::new(io, BytesCodec);
Ok::<_, ()>(()) f.send(Bytes::from_static(b"test")).await.unwrap();
Ok::<_, ()>(())
})
}) })
}) .unwrap()
.unwrap() .start()
.start(); });
let _ = tx.send((srv, ntex::rt::System::current())); let _ = tx.send((srv, ntex::rt::System::current()));
let _ = sys.run(); let _ = sys.run();
@ -144,29 +150,31 @@ fn test_configure() {
let h = thread::spawn(move || { let h = thread::spawn(move || {
let num = num2.clone(); let num = num2.clone();
let sys = ntex::rt::System::new("test"); let mut sys = ntex::rt::System::new("test");
let srv = Server::build() let srv = sys.exec(|| {
.disable_signals() Server::build()
.configure(move |cfg| { .disable_signals()
let num = num.clone(); .configure(move |cfg| {
let lst = net::TcpListener::bind(addr3).unwrap(); let num = num.clone();
cfg.bind("addr1", addr1) let lst = net::TcpListener::bind(addr3).unwrap();
.unwrap() cfg.bind("addr1", addr1)
.bind("addr2", addr2) .unwrap()
.unwrap() .bind("addr2", addr2)
.listen("addr3", lst) .unwrap()
.apply(move |rt| { .listen("addr3", lst)
let num = num.clone(); .apply(move |rt| {
rt.service("addr1", fn_service(|_| ok::<_, ()>(()))); let num = num.clone();
rt.service("addr3", fn_service(|_| ok::<_, ()>(()))); rt.service("addr1", fn_service(|_| ok::<_, ()>(())));
rt.on_start(lazy(move |_| { rt.service("addr3", fn_service(|_| ok::<_, ()>(())));
let _ = num.fetch_add(1, Relaxed); rt.on_start(lazy(move |_| {
})) let _ = num.fetch_add(1, Relaxed);
}) }))
}) })
.unwrap() })
.workers(1) .unwrap()
.start(); .workers(1)
.start()
});
let _ = tx.send((srv, ntex::rt::System::current())); let _ = tx.send((srv, ntex::rt::System::current()));
let _ = sys.run(); let _ = sys.run();
}); });

View file

@ -23,27 +23,29 @@ async fn test_start() {
let (tx, rx) = mpsc::channel(); let (tx, rx) = mpsc::channel();
thread::spawn(move || { thread::spawn(move || {
let sys = ntex::rt::System::new("test"); let mut sys = ntex::rt::System::new("test");
let srv = HttpServer::new(|| { let srv = sys.exec(|| {
App::new().service( HttpServer::new(|| {
web::resource("/") App::new().service(
.route(web::to(|| async { HttpResponse::Ok().body("test") })), web::resource("/")
) .route(web::to(|| async { HttpResponse::Ok().body("test") })),
}) )
.workers(1) })
.backlog(1) .workers(1)
.maxconn(10) .backlog(1)
.maxconnrate(10) .maxconn(10)
.keep_alive(10) .maxconnrate(10)
.client_timeout(5000) .keep_alive(10)
.client_shutdown(0) .client_timeout(5000)
.server_hostname("localhost") .client_shutdown(0)
.system_exit() .server_hostname("localhost")
.disable_signals() .system_exit()
.bind(format!("{}", addr)) .disable_signals()
.unwrap() .bind(format!("{}", addr))
.run(); .unwrap()
.run()
});
let _ = tx.send((srv, ntex::rt::System::current())); let _ = tx.send((srv, ntex::rt::System::current()));
let _ = sys.run(); let _ = sys.run();
@ -94,24 +96,26 @@ async fn test_start_ssl() {
let (tx, rx) = mpsc::channel(); let (tx, rx) = mpsc::channel();
thread::spawn(move || { thread::spawn(move || {
let sys = ntex::rt::System::new("test"); let mut sys = ntex::rt::System::new("test");
let builder = ssl_acceptor().unwrap(); let builder = ssl_acceptor().unwrap();
let srv = HttpServer::new(|| { let srv = sys.exec(|| {
App::new().service(web::resource("/").route(web::to( HttpServer::new(|| {
|req: HttpRequest| async move { App::new().service(web::resource("/").route(web::to(
assert!(req.app_config().secure()); |req: HttpRequest| async move {
HttpResponse::Ok().body("test") assert!(req.app_config().secure());
}, HttpResponse::Ok().body("test")
))) },
}) )))
.workers(1) })
.shutdown_timeout(1) .workers(1)
.system_exit() .shutdown_timeout(1)
.disable_signals() .system_exit()
.bind_openssl(format!("{}", addr), builder) .disable_signals()
.unwrap() .bind_openssl(format!("{}", addr), builder)
.run(); .unwrap()
.run()
});
let _ = tx.send((srv, ntex::rt::System::current())); let _ = tx.send((srv, ntex::rt::System::current()));
let _ = sys.run(); let _ = sys.run();