Clippy warnings (#305)

This commit is contained in:
Nikolay Kim 2024-03-06 20:33:20 +06:00 committed by GitHub
parent bd2b4583cd
commit 044991c170
No known key found for this signature in database
GPG key ID: B5690EEEBB952194
66 changed files with 142 additions and 127 deletions

View file

@ -1,7 +1,7 @@
use std::{cell::RefCell, future::Future, pin::Pin, rc::Rc, task::Context, task::Poll}; use std::{cell::RefCell, future::Future, pin::Pin, rc::Rc, task::Context, task::Poll};
thread_local! { thread_local! {
static SRUN: RefCell<bool> = RefCell::new(false); static SRUN: RefCell<bool> = const { RefCell::new(false) };
static SHANDLERS: Rc<RefCell<Vec<oneshot::Sender<Signal>>>> = Default::default(); static SHANDLERS: Rc<RefCell<Vec<oneshot::Sender<Signal>>>> = Default::default();
} }

View file

@ -4179,7 +4179,11 @@ mod tests {
} }
#[test] #[test]
#[allow(clippy::len_zero)] #[allow(
clippy::len_zero,
clippy::nonminimal_bool,
clippy::unnecessary_fallible_conversions
)]
fn bytes() { fn bytes() {
let mut b = Bytes::from(LONG.to_vec()); let mut b = Bytes::from(LONG.to_vec());
b.clear(); b.clear();
@ -4226,6 +4230,7 @@ mod tests {
} }
#[test] #[test]
#[allow(clippy::unnecessary_fallible_conversions)]
fn bytes_vec() { fn bytes_vec() {
let bv = BytesVec::copy_from_slice(LONG); let bv = BytesVec::copy_from_slice(LONG);
// SharedVec size is 32 // SharedVec size is 32

View file

@ -371,7 +371,7 @@ mod utf8 {
#[cfg(test)] #[cfg(test)]
mod test { mod test {
use std::borrow::{Borrow, Cow, ToOwned}; use std::borrow::{Borrow, Cow};
use std::collections::hash_map::DefaultHasher; use std::collections::hash_map::DefaultHasher;
use std::hash::{Hash, Hasher}; use std::hash::{Hash, Hasher};

View file

@ -1,4 +1,5 @@
#![deny(warnings, rust_2018_idioms)] #![deny(warnings, rust_2018_idioms)]
#![allow(clippy::unnecessary_mut_passed)]
use ntex_bytes::{Buf, Bytes, BytesMut}; use ntex_bytes::{Buf, Bytes, BytesMut};

View file

@ -1,3 +1,4 @@
#![allow(clippy::op_ref, clippy::let_underscore_future)]
use std::{borrow::Borrow, borrow::BorrowMut, task::Poll}; use std::{borrow::Borrow, borrow::BorrowMut, task::Poll};
use ntex_bytes::{Buf, BufMut, Bytes, BytesMut, BytesVec, Pool, PoolId, PoolRef}; use ntex_bytes::{Buf, BufMut, Bytes, BytesMut, BytesVec, Pool, PoolId, PoolRef};

View file

@ -124,7 +124,6 @@ impl<T: Address> Service<Connect<T>> for Connector<T> {
#[cfg(test)] #[cfg(test)]
mod tests { mod tests {
use super::*; use super::*;
use ntex_service::ServiceFactory;
#[ntex::test] #[ntex::test]
async fn test_openssl_connect() { async fn test_openssl_connect() {

View file

@ -126,11 +126,9 @@ impl<T: Address> Service<Connect<T>> for Connector<T> {
#[cfg(test)] #[cfg(test)]
mod tests { mod tests {
use std::sync::Arc;
use tls_rustls::{OwnedTrustAnchor, RootCertStore}; use tls_rustls::{OwnedTrustAnchor, RootCertStore};
use super::*; use super::*;
use ntex_service::ServiceFactory;
use ntex_util::future::lazy; use ntex_util::future::lazy;
#[ntex::test] #[ntex::test]

View file

@ -579,7 +579,7 @@ mod tests {
} }
#[test] #[test]
#[allow(clippy::needless_borrow)] #[allow(clippy::needless_borrow, clippy::needless_borrows_for_generic_args)]
fn test_basics() { fn test_basics() {
let m = HeaderMap::default(); let m = HeaderMap::default();
assert!(m.is_empty()); assert!(m.is_empty());

View file

@ -85,6 +85,7 @@ impl HeaderValue {
let mut i = 0; let mut i = 0;
while i < bytes.len() { while i < bytes.len() {
if !is_visible_ascii(bytes[i]) { if !is_visible_ascii(bytes[i]) {
#[allow(clippy::out_of_bounds_indexing)]
([] as [u8; 0])[0]; // Invalid header value ([] as [u8; 0])[0]; // Invalid header value
} }
i += 1; i += 1;

View file

@ -1,4 +1,5 @@
//! Framed transport dispatcher //! Framed transport dispatcher
#![allow(clippy::let_underscore_future)]
use std::{cell::Cell, future, pin::Pin, rc::Rc, task::Context, task::Poll}; use std::{cell::Cell, future, pin::Pin, rc::Rc, task::Context, task::Poll};
use ntex_bytes::Pool; use ntex_bytes::Pool;
@ -341,7 +342,7 @@ where
// call service // call service
let shared = slf.shared.clone(); let shared = slf.shared.clone();
shared.inflight.set(shared.inflight.get() + 1); shared.inflight.set(shared.inflight.get() + 1);
spawn(async move { let _ = spawn(async move {
let result = shared.service.call(item).await; let result = shared.service.call(item).await;
shared.handle_result(result, &shared.io); shared.handle_result(result, &shared.io);
}); });
@ -365,7 +366,7 @@ where
// call service // call service
let shared = slf.shared.clone(); let shared = slf.shared.clone();
shared.inflight.set(shared.inflight.get() + 1); shared.inflight.set(shared.inflight.get() + 1);
spawn(async move { let _ = spawn(async move {
let result = shared.service.call(item).await; let result = shared.service.call(item).await;
shared.handle_result(result, &shared.io); shared.handle_result(result, &shared.io);
}); });
@ -595,7 +596,7 @@ mod tests {
use ntex_bytes::{Bytes, BytesMut, PoolId, PoolRef}; use ntex_bytes::{Bytes, BytesMut, PoolId, PoolRef};
use ntex_codec::BytesCodec; use ntex_codec::BytesCodec;
use ntex_service::ServiceCtx; use ntex_service::ServiceCtx;
use ntex_util::{time::sleep, time::Millis, time::Seconds}; use ntex_util::{time::sleep, time::Millis};
use super::*; use super::*;
use crate::{io::Flags, testing::IoTest, Io, IoRef, IoStream}; use crate::{io::Flags, testing::IoTest, Io, IoRef, IoStream};

View file

@ -932,7 +932,7 @@ mod tests {
use ntex_codec::BytesCodec; use ntex_codec::BytesCodec;
use super::*; use super::*;
use crate::{testing::IoTest, FilterLayer, Io, ReadBuf, WriteBuf}; use crate::{testing::IoTest, ReadBuf, WriteBuf};
const BIN: &[u8] = b"GET /test HTTP/1\r\n\r\n"; const BIN: &[u8] = b"GET /test HTTP/1\r\n\r\n";
const TEXT: &str = "GET /test HTTP/1\r\n\r\n"; const TEXT: &str = "GET /test HTTP/1\r\n\r\n";

View file

@ -119,8 +119,7 @@ impl IoRef {
}) })
// .with_write_buf() could return io::Error<Result<(), U::Error>>, // .with_write_buf() could return io::Error<Result<(), U::Error>>,
// in that case mark io as failed // in that case mark io as failed
.map_or_else( .unwrap_or_else(|err| {
|err| {
log::trace!( log::trace!(
"{}: Got io error while encoding, error: {:?}", "{}: Got io error while encoding, error: {:?}",
self.tag(), self.tag(),
@ -128,9 +127,7 @@ impl IoRef {
); );
self.0.io_stopped(Some(err)); self.0.io_stopped(Some(err));
Ok(()) Ok(())
}, })
|item| item,
)
} else { } else {
log::trace!("{}: Io is closed/closing, skip frame encoding", self.tag()); log::trace!("{}: Io is closed/closing, skip frame encoding", self.tag());
Ok(()) Ok(())
@ -318,7 +315,7 @@ mod tests {
use ntex_util::time::{sleep, Millis}; use ntex_util::time::{sleep, Millis};
use super::*; use super::*;
use crate::{testing::IoTest, FilterLayer, Io, ReadBuf, WriteBuf}; use crate::{testing::IoTest, FilterLayer, Io, ReadBuf};
const BIN: &[u8] = b"GET /test HTTP/1\r\n\r\n"; const BIN: &[u8] = b"GET /test HTTP/1\r\n\r\n";
const TEXT: &str = "GET /test HTTP/1\r\n\r\n"; const TEXT: &str = "GET /test HTTP/1\r\n\r\n";

View file

@ -1,4 +1,5 @@
//! utilities and helpers for testing //! utilities and helpers for testing
#![allow(clippy::let_underscore_future)]
use std::future::{poll_fn, Future}; use std::future::{poll_fn, Future};
use std::sync::{Arc, Mutex}; use std::sync::{Arc, Mutex};
use std::task::{ready, Context, Poll, Waker}; use std::task::{ready, Context, Poll, Waker};
@ -355,11 +356,11 @@ impl IoStream for IoTest {
fn start(self, read: ReadContext, write: WriteContext) -> Option<Box<dyn Handle>> { fn start(self, read: ReadContext, write: WriteContext) -> Option<Box<dyn Handle>> {
let io = Rc::new(self); let io = Rc::new(self);
ntex_util::spawn(ReadTask { let _ = ntex_util::spawn(ReadTask {
io: io.clone(), io: io.clone(),
state: read, state: read,
}); });
ntex_util::spawn(WriteTask { let _ = ntex_util::spawn(WriteTask {
io: io.clone(), io: io.clone(),
state: write, state: write,
st: IoWriteState::Processing(None), st: IoWriteState::Processing(None),

View file

@ -127,7 +127,8 @@ pub(crate) fn register(timeout: Seconds, io: &IoRef) -> TimerHandle {
if !timer.running.get() { if !timer.running.get() {
timer.running.set(true); timer.running.set(true);
spawn(async move { #[allow(clippy::let_underscore_future)]
let _ = spawn(async move {
let guard = TimerGuard; let guard = TimerGuard;
loop { loop {
sleep(SEC).await; sleep(SEC).await;

View file

@ -491,11 +491,10 @@ impl<'de> de::VariantAccess<'de> for UnitVariant {
#[cfg(test)] #[cfg(test)]
mod tests { mod tests {
use serde::de;
use serde_derive::Deserialize; use serde_derive::Deserialize;
use super::*; use super::*;
use crate::path::{Path, PathItem}; use crate::path::PathItem;
#[derive(Deserialize)] #[derive(Deserialize)]
struct MyStruct { struct MyStruct {

View file

@ -754,6 +754,7 @@ mod tests {
} }
#[test] #[test]
#[allow(clippy::needless_borrows_for_generic_args)]
fn test_static_tail() { fn test_static_tail() {
let re = ResourceDef::new("/*".to_string()); let re = ResourceDef::new("/*".to_string());
let tree = Tree::new(&re, 1); let tree = Tree::new(&re, 1);

View file

@ -1,3 +1,4 @@
#![allow(clippy::let_underscore_future)]
use std::any::{Any, TypeId}; use std::any::{Any, TypeId};
use std::sync::atomic::{AtomicUsize, Ordering}; use std::sync::atomic::{AtomicUsize, Ordering};
use std::task::{Context, Poll}; use std::task::{Context, Poll};
@ -9,7 +10,7 @@ use futures_core::stream::Stream;
use crate::system::System; use crate::system::System;
thread_local!( thread_local!(
static ADDR: RefCell<Option<Arbiter>> = RefCell::new(None); static ADDR: RefCell<Option<Arbiter>> = const { RefCell::new(None) };
static STORAGE: RefCell<HashMap<TypeId, Box<dyn Any>>> = RefCell::new(HashMap::new()); static STORAGE: RefCell<HashMap<TypeId, Box<dyn Any>>> = RefCell::new(HashMap::new());
); );
@ -103,7 +104,7 @@ impl Arbiter {
crate::block_on(async move { crate::block_on(async move {
// start arbiter controller // start arbiter controller
crate::spawn(ArbiterController { let _ = crate::spawn(ArbiterController {
stop: Some(stop), stop: Some(stop),
rx: Box::pin(arb_rx), rx: Box::pin(arb_rx),
}); });
@ -268,7 +269,7 @@ impl Future for ArbiterController {
return Poll::Ready(()); return Poll::Ready(());
} }
ArbiterCommand::Execute(fut) => { ArbiterCommand::Execute(fut) => {
crate::spawn(fut); let _ = crate::spawn(fut);
} }
ArbiterCommand::ExecuteFn(f) => { ArbiterCommand::ExecuteFn(f) => {
f.call_box(); f.call_box();

View file

@ -1,3 +1,4 @@
#![allow(clippy::let_underscore_future)]
use std::{cell::RefCell, future::Future, io, rc::Rc}; use std::{cell::RefCell, future::Future, io, rc::Rc};
use async_channel::unbounded; use async_channel::unbounded;
@ -159,8 +160,8 @@ where
let result = Rc::new(RefCell::new(None)); let result = Rc::new(RefCell::new(None));
let result_inner = result.clone(); let result_inner = result.clone();
crate::block_on(Box::pin(async move { crate::block_on(Box::pin(async move {
crate::spawn(arb); let _ = crate::spawn(arb);
crate::spawn(arb_controller); let _ = crate::spawn(arb_controller);
if let Err(e) = f() { if let Err(e) = f() {
*result_inner.borrow_mut() = Some(Err(e)); *result_inner.borrow_mut() = Some(Err(e));
} else { } else {

View file

@ -16,7 +16,7 @@ pub struct System {
} }
thread_local!( thread_local!(
static CURRENT: RefCell<Option<System>> = RefCell::new(None); static CURRENT: RefCell<Option<System>> = const { RefCell::new(None) };
); );
impl System { impl System {

View file

@ -203,7 +203,7 @@ mod tests {
use std::task::Poll; use std::task::Poll;
use super::*; use super::*;
use crate::{chain, chain_factory, Service, ServiceCtx}; use crate::{chain, chain_factory};
#[derive(Clone, Debug)] #[derive(Clone, Debug)]
struct Srv; struct Srv;

View file

@ -193,10 +193,10 @@ impl<'a, S> fmt::Debug for ServiceCtx<'a, S> {
#[cfg(test)] #[cfg(test)]
mod tests { mod tests {
use ntex_util::future::lazy; use std::task::Context;
use ntex_util::{channel::condition, time}; use std::{cell::Cell, cell::RefCell};
use std::task::{Context, Poll};
use std::{cell::Cell, cell::RefCell, future::poll_fn, rc::Rc}; use ntex_util::{channel::condition, future::lazy, time};
use super::*; use super::*;
use crate::Pipeline; use crate::Pipeline;
@ -218,6 +218,7 @@ mod tests {
ctx: ServiceCtx<'_, Self>, ctx: ServiceCtx<'_, Self>,
) -> Result<Self::Response, Self::Error> { ) -> Result<Self::Response, Self::Error> {
format!("{:?}", ctx); format!("{:?}", ctx);
#[allow(clippy::clone_on_copy)]
let _ = ctx.clone(); let _ = ctx.clone();
Ok(req) Ok(req)
} }

View file

@ -389,7 +389,7 @@ mod tests {
use std::task::Poll; use std::task::Poll;
use super::*; use super::*;
use crate::{Pipeline, ServiceFactory}; use crate::Pipeline;
#[ntex::test] #[ntex::test]
async fn test_fn_service() { async fn test_fn_service() {

View file

@ -72,7 +72,7 @@ where
#[cfg(test)] #[cfg(test)]
mod tests { mod tests {
use ntex_util::future::lazy; use ntex_util::future::lazy;
use std::{rc::Rc, task::Poll}; use std::rc::Rc;
use crate::{chain, fn_service, Pipeline}; use crate::{chain, fn_service, Pipeline};

View file

@ -119,7 +119,7 @@ mod tests {
use std::{cell::Cell, rc::Rc}; use std::{cell::Cell, rc::Rc};
use super::*; use super::*;
use crate::{fn_service, ServiceFactory}; use crate::fn_service;
#[ntex::test] #[ntex::test]
async fn test_map_config() { async fn test_map_config() {

View file

@ -161,7 +161,7 @@ mod tests {
use ntex_util::future::{lazy, Ready}; use ntex_util::future::{lazy, Ready};
use super::*; use super::*;
use crate::{fn_factory, Pipeline, Service, ServiceCtx, ServiceFactory}; use crate::{fn_factory, Pipeline};
#[derive(Debug, Clone)] #[derive(Debug, Clone)]
struct Srv(bool); struct Srv(bool);

View file

@ -187,7 +187,7 @@ mod tests {
use std::task::{Context, Poll}; use std::task::{Context, Poll};
use super::*; use super::*;
use crate::{fn_service, Pipeline, Service, ServiceCtx, ServiceFactory}; use crate::{fn_service, Pipeline, ServiceCtx};
#[derive(Debug, Clone)] #[derive(Debug, Clone)]
struct Tr<R>(PhantomData<R>); struct Tr<R>(PhantomData<R>);

View file

@ -6,7 +6,7 @@ use tokio::sync::oneshot;
use tokio::task::spawn_local; use tokio::task::spawn_local;
thread_local! { thread_local! {
static SRUN: RefCell<bool> = RefCell::new(false); static SRUN: RefCell<bool> = const { RefCell::new(false) };
static SHANDLERS: Rc<RefCell<Vec<oneshot::Sender<Signal>>>> = Default::default(); static SHANDLERS: Rc<RefCell<Vec<oneshot::Sender<Signal>>>> = Default::default();
} }

View file

@ -252,8 +252,7 @@ impl<T> SendError<T> {
#[cfg(test)] #[cfg(test)]
mod tests { mod tests {
use super::*; use super::*;
use crate::{future::lazy, future::stream_recv, Stream}; use crate::{future::lazy, future::stream_recv};
use futures_sink::Sink;
#[ntex_macros::rt_test2] #[ntex_macros::rt_test2]
async fn test_mpsc() { async fn test_mpsc() {

View file

@ -287,8 +287,8 @@ where
#[cfg(test)] #[cfg(test)]
mod tests { mod tests {
use ntex_service::{apply, fn_factory, Pipeline, Service, ServiceFactory}; use ntex_service::{apply, fn_factory, Pipeline, ServiceFactory};
use std::{rc::Rc, task::Context, task::Poll, time::Duration}; use std::{rc::Rc, time::Duration};
use super::*; use super::*;
use crate::future::lazy; use crate::future::lazy;

View file

@ -1,4 +1,4 @@
use std::{any::Any, any::TypeId, fmt, iter::Extend}; use std::{any::Any, any::TypeId, fmt};
#[derive(Default)] #[derive(Default)]
/// A type map of request extensions. /// A type map of request extensions.

View file

@ -90,8 +90,8 @@ where
#[cfg(test)] #[cfg(test)]
mod tests { mod tests {
use ntex_service::{apply, fn_factory, Pipeline, Service, ServiceCtx, ServiceFactory}; use ntex_service::{apply, fn_factory, Pipeline, ServiceFactory};
use std::{cell::RefCell, task::Poll, time::Duration}; use std::{cell::RefCell, time::Duration};
use super::*; use super::*;
use crate::{channel::oneshot, future::lazy}; use crate::{channel::oneshot, future::lazy};

View file

@ -138,8 +138,6 @@ where
#[cfg(test)] #[cfg(test)]
mod tests { mod tests {
use ntex_service::ServiceFactory;
use super::*; use super::*;
use crate::future::lazy; use crate::future::lazy;

View file

@ -81,8 +81,8 @@ where
#[cfg(test)] #[cfg(test)]
mod tests { mod tests {
use ntex_service::{apply, fn_factory, Pipeline, Service, ServiceCtx, ServiceFactory}; use ntex_service::{apply, fn_factory, Pipeline, ServiceFactory};
use std::{cell::RefCell, task::Poll, time::Duration}; use std::{cell::RefCell, time::Duration};
use super::*; use super::*;
use crate::{channel::oneshot, future::lazy}; use crate::{channel::oneshot, future::lazy};

View file

@ -147,9 +147,9 @@ where
#[cfg(test)] #[cfg(test)]
mod tests { mod tests {
use std::{fmt, time::Duration}; use std::time::Duration;
use ntex_service::{apply, fn_factory, Pipeline, Service, ServiceFactory}; use ntex_service::{apply, fn_factory, Pipeline, ServiceFactory};
use super::*; use super::*;
use crate::future::lazy; use crate::future::lazy;

View file

@ -232,8 +232,7 @@ variant_impl_and!(VariantFactory7, VariantFactory8, V8, V8R, v8, (V2, V3, V4, V5
#[cfg(test)] #[cfg(test)]
mod tests { mod tests {
use ntex_service::{fn_factory, Service, ServiceFactory}; use ntex_service::fn_factory;
use std::task::{Context, Poll};
use super::*; use super::*;
use crate::future::lazy; use crate::future::lazy;

View file

@ -339,6 +339,7 @@ impl crate::Stream for Interval {
} }
#[cfg(test)] #[cfg(test)]
#[allow(clippy::let_underscore_future)]
mod tests { mod tests {
use futures_util::StreamExt; use futures_util::StreamExt;
use std::time; use std::time;

View file

@ -1,7 +1,7 @@
//! Time wheel based timer service. //! Time wheel based timer service.
//! //!
//! Inspired by linux kernel timers system //! Inspired by linux kernel timers system
#![allow(arithmetic_overflow)] #![allow(arithmetic_overflow, clippy::let_underscore_future)]
use std::cell::{Cell, RefCell}; use std::cell::{Cell, RefCell};
use std::time::{Duration, Instant, SystemTime}; use std::time::{Duration, Instant, SystemTime};
use std::{cmp::max, future::Future, mem, pin::Pin, rc::Rc, task, task::Poll}; use std::{cmp::max, future::Future, mem, pin::Pin, rc::Rc, task, task::Poll};
@ -611,7 +611,7 @@ impl TimerDriver {
timer.inner.borrow_mut().driver_sleep = timer.inner.borrow_mut().driver_sleep =
Delay::new(Duration::from_millis(timer.next_expiry_ms())); Delay::new(Duration::from_millis(timer.next_expiry_ms()));
crate::spawn(TimerDriver(timer)); let _ = crate::spawn(TimerDriver(timer));
} }
} }
@ -676,7 +676,7 @@ impl LowresTimerDriver {
timer.flags.set(flags); timer.flags.set(flags);
timer.inner.borrow_mut().lowres_driver_sleep = Delay::new(LOWRES_RESOLUTION); timer.inner.borrow_mut().lowres_driver_sleep = Delay::new(LOWRES_RESOLUTION);
crate::spawn(LowresTimerDriver(timer)); let _ = crate::spawn(LowresTimerDriver(timer));
} }
} }

View file

@ -388,8 +388,9 @@ where
} }
pin_project_lite::pin_project! { pin_project_lite::pin_project! {
struct OpenConnection<T: Service<Connect>> struct OpenConnection<T>
where T: 'static where T: Service<Connect>,
T: 'static
{ {
key: Key, key: Key,
#[pin] #[pin]
@ -610,11 +611,9 @@ impl Drop for Acquired {
#[cfg(test)] #[cfg(test)]
mod tests { mod tests {
use std::{cell::RefCell, rc::Rc};
use super::*; use super::*;
use crate::time::{sleep, Millis}; use crate::time::{sleep, Millis};
use crate::{http::Uri, io as nio, service::fn_service, testing::Io, util::lazy}; use crate::{io as nio, service::fn_service, testing::Io, util::lazy};
#[crate::rt_test] #[crate::rt_test]
async fn test_basics() { async fn test_basics() {

View file

@ -583,6 +583,7 @@ mod tests {
} }
#[crate::rt_test] #[crate::rt_test]
#[allow(clippy::let_underscore_future)]
async fn test_basics() { async fn test_basics() {
let mut req = Client::new() let mut req = Client::new()
.put("/") .put("/")

View file

@ -238,8 +238,7 @@ impl From<BlockingError<io::Error>> for PayloadError {
#[cfg(test)] #[cfg(test)]
mod tests { mod tests {
use super::*; use super::*;
use ntex_http::{Error as HttpError, StatusCode}; use ntex_http::Error as HttpError;
use std::io;
#[test] #[test]
fn test_into_response() { fn test_into_response() {

View file

@ -197,8 +197,8 @@ impl Encoder for Codec {
#[cfg(test)] #[cfg(test)]
mod tests { mod tests {
use super::*; use super::*;
use crate::http::{h1::PayloadItem, HttpMessage, Method}; use crate::http::{h1::PayloadItem, HttpMessage};
use crate::util::{Bytes, BytesMut}; use crate::util::Bytes;
#[test] #[test]
fn test_http_request_chunked_payload_and_next_message() { fn test_http_request_chunked_payload_and_next_message() {

View file

@ -740,9 +740,8 @@ fn uninit_array<T, const LEN: usize>() -> [mem::MaybeUninit<T>; LEN] {
#[cfg(test)] #[cfg(test)]
mod tests { mod tests {
use super::*; use super::*;
use crate::http::header::{HeaderName, SET_COOKIE}; use crate::http::header::SET_COOKIE;
use crate::http::{HttpMessage, Method, Version}; use crate::http::HttpMessage;
use crate::util::{Bytes, BytesMut};
impl PayloadType { impl PayloadType {
fn unwrap(self) -> PayloadDecoder { fn unwrap(self) -> PayloadDecoder {

View file

@ -838,19 +838,19 @@ where
#[cfg(test)] #[cfg(test)]
mod tests { mod tests {
use std::sync::atomic::{AtomicBool, AtomicUsize, Ordering}; use std::sync::atomic::{AtomicBool, AtomicUsize, Ordering};
use std::{cell::Cell, future::poll_fn, future::Future, io, sync::Arc}; use std::{cell::Cell, future::poll_fn, future::Future, sync::Arc};
use ntex_h2::Config; use ntex_h2::Config;
use rand::Rng; use rand::Rng;
use super::*; use super::*;
use crate::http::config::{DispatcherConfig, ServiceConfig}; use crate::http::config::ServiceConfig;
use crate::http::h1::{ClientCodec, DefaultControlService}; use crate::http::h1::{ClientCodec, DefaultControlService};
use crate::http::{body, Request, ResponseHead, StatusCode}; use crate::http::{body, ResponseHead, StatusCode};
use crate::io::{self as nio, Base}; use crate::io::{self as nio, Base};
use crate::service::{fn_service, IntoService}; use crate::service::{fn_service, IntoService};
use crate::util::{lazy, stream_recv, Bytes, BytesMut}; use crate::util::{lazy, stream_recv, Bytes, BytesMut};
use crate::{codec::Decoder, testing::Io, time::sleep, time::Millis, time::Seconds}; use crate::{codec::Decoder, testing::Io, time::sleep, time::Millis};
const BUFFER_SIZE: usize = 32_768; const BUFFER_SIZE: usize = 32_768;

View file

@ -83,8 +83,6 @@ mod openssl {
#[cfg(feature = "rustls")] #[cfg(feature = "rustls")]
mod rustls { mod rustls {
use std::fmt;
use ntex_tls::rustls::{TlsAcceptor, TlsServerFilter}; use ntex_tls::rustls::{TlsAcceptor, TlsServerFilter};
use tls_rustls::ServerConfig; use tls_rustls::ServerConfig;

View file

@ -808,8 +808,7 @@ impl From<BytesMut> for Response {
#[cfg(test)] #[cfg(test)]
mod tests { mod tests {
use super::*; use super::*;
use crate::http::body::Body; use crate::http::header::{CONTENT_TYPE, COOKIE};
use crate::http::header::{HeaderValue, CONTENT_TYPE, COOKIE};
#[test] #[test]
fn test_debug() { fn test_debug() {

View file

@ -6,7 +6,7 @@ use polling::{Event, Events, Poller};
use crate::{rt::System, time::sleep, time::Millis, util::Either}; use crate::{rt::System, time::sleep, time::Millis, util::Either};
use super::socket::{Listener, SocketAddr, Stream}; use super::socket::{Listener, SocketAddr, Stream};
use super::worker::{WorkerMessage, WorkerClient, WorkerManagerCmd, WorkerManagerNotifier}; use super::worker::{WorkerClient, WorkerManagerCmd, WorkerManagerNotifier, WorkerMessage};
use super::{Server, ServerStatus, Token}; use super::{Server, ServerStatus, Token};
const EXIT_TIMEOUT: Duration = Duration::from_millis(100); const EXIT_TIMEOUT: Duration = Duration::from_millis(100);
@ -26,7 +26,10 @@ struct ServerSocketInfo {
pub(super) struct AcceptNotify(Arc<Poller>, mpsc::Sender<WorkerManagerCmd<Stream>>); pub(super) struct AcceptNotify(Arc<Poller>, mpsc::Sender<WorkerManagerCmd<Stream>>);
impl AcceptNotify { impl AcceptNotify {
pub(super) fn new(waker: Arc<Poller>, tx: mpsc::Sender<WorkerManagerCmd<Stream>>) -> Self { pub(super) fn new(
waker: Arc<Poller>,
tx: mpsc::Sender<WorkerManagerCmd<Stream>>,
) -> Self {
AcceptNotify(waker, tx) AcceptNotify(waker, tx)
} }
} }
@ -44,7 +47,11 @@ impl WorkerManagerNotifier<Stream> for AcceptNotify {
pub(super) struct AcceptLoop { pub(super) struct AcceptLoop {
notify: AcceptNotify, notify: AcceptNotify,
inner: Option<(mpsc::Receiver<WorkerManagerCmd<Stream>>, Arc<Poller>, Server)>, inner: Option<(
mpsc::Receiver<WorkerManagerCmd<Stream>>,
Arc<Poller>,
Server,
)>,
status_handler: Option<Box<dyn FnMut(ServerStatus) + Send>>, status_handler: Option<Box<dyn FnMut(ServerStatus) + Send>>,
} }

View file

@ -13,8 +13,8 @@ use super::config::{
Config, ConfigWrapper, ConfiguredService, ServiceConfig, ServiceRuntime, Config, ConfigWrapper, ConfiguredService, ServiceConfig, ServiceRuntime,
}; };
use super::service::{Factory, InternalServiceFactory}; use super::service::{Factory, InternalServiceFactory};
use super::worker::{self, WorkerManagerCmd, Worker, WorkerAvailability, WorkerClient}; use super::worker::{self, Worker, WorkerAvailability, WorkerClient, WorkerManagerCmd};
use super::{socket::Listener, Server, ServerCommand, ServerStatus, Token, socket}; use super::{socket, socket::Listener, Server, ServerCommand, ServerStatus, Token};
const STOP_DELAY: Millis = Millis(300); const STOP_DELAY: Millis = Millis(300);
@ -381,7 +381,11 @@ impl ServerBuilder {
} }
} }
fn start_worker(&self, idx: usize, notify: AcceptNotify) -> WorkerClient<socket::Stream> { fn start_worker(
&self,
idx: usize,
notify: AcceptNotify,
) -> WorkerClient<socket::Stream> {
let avail = WorkerAvailability::new(Box::new(notify)); let avail = WorkerAvailability::new(Box::new(notify));
let services: Vec<Box<dyn InternalServiceFactory<socket::Stream>>> = let services: Vec<Box<dyn InternalServiceFactory<socket::Stream>>> =
self.services.iter().map(|v| v.clone_factory()).collect(); self.services.iter().map(|v| v.clone_factory()).collect();

View file

@ -185,7 +185,9 @@ impl InternalServiceFactory<Stream> for ConfiguredService {
}) })
} }
fn create(&self) -> BoxFuture<'static, Result<Vec<(Token, BoxedServerService<Stream>)>, ()>> { fn create(
&self,
) -> BoxFuture<'static, Result<Vec<(Token, BoxedServerService<Stream>)>, ()>> {
// configure services // configure services
let rt = ServiceRuntime::new(self.topics.clone()); let rt = ServiceRuntime::new(self.topics.clone());
let cfg_fut = self.rt.configure(ServiceRuntime(rt.0.clone())); let cfg_fut = self.rt.configure(ServiceRuntime(rt.0.clone()));
@ -387,7 +389,8 @@ struct ServiceFactory<T> {
pool: PoolId, pool: PoolId,
} }
impl<T> service::ServiceFactory<(Option<CounterGuard>, ServerMessage<Stream>)> for ServiceFactory<T> impl<T> service::ServiceFactory<(Option<CounterGuard>, ServerMessage<Stream>)>
for ServiceFactory<T>
where where
T: service::ServiceFactory<Io>, T: service::ServiceFactory<Io>,
T::Service: 'static, T::Service: 'static,

View file

@ -31,7 +31,8 @@ pub trait InternalServiceFactory<T>: Send {
fn clone_factory(&self) -> Box<dyn InternalServiceFactory<T>>; fn clone_factory(&self) -> Box<dyn InternalServiceFactory<T>>;
fn create(&self) -> BoxFuture<'static, Result<Vec<(Token, BoxedServerService<T>)>, ()>>; fn create(&self)
-> BoxFuture<'static, Result<Vec<(Token, BoxedServerService<T>)>, ()>>;
} }
pub type BoxedServerService<T> = pub type BoxedServerService<T> =
@ -154,7 +155,9 @@ where
}) })
} }
fn create(&self) -> BoxFuture<'static, Result<Vec<(Token, BoxedServerService<Stream>)>, ()>> { fn create(
&self,
) -> BoxFuture<'static, Result<Vec<(Token, BoxedServerService<Stream>)>, ()>> {
let token = self.token; let token = self.token;
let tag = self.tag; let tag = self.tag;
let cfg = Config::default(); let cfg = Config::default();
@ -186,7 +189,9 @@ impl<T> InternalServiceFactory<T> for Box<dyn InternalServiceFactory<T>> {
self.as_ref().clone_factory() self.as_ref().clone_factory()
} }
fn create(&self) -> BoxFuture<'static, Result<Vec<(Token, BoxedServerService<T>)>, ()>> { fn create(
&self,
) -> BoxFuture<'static, Result<Vec<(Token, BoxedServerService<T>)>, ()>> {
self.as_ref().create() self.as_ref().create()
} }
} }

View file

@ -1,16 +1,16 @@
use std::sync::atomic::{AtomicBool, AtomicUsize, Ordering}; use std::sync::atomic::{AtomicBool, AtomicUsize, Ordering};
use std::{fmt, future::Future, pin::Pin, sync::Arc, task::Context, task::Poll};
use std::sync::mpsc; use std::sync::mpsc;
use std::{fmt, future::Future, pin::Pin, sync::Arc, task::Context, task::Poll};
use async_channel::{unbounded, Receiver, Sender}; use async_channel::{unbounded, Receiver, Sender};
use crate::rt::{spawn, Arbiter}; use crate::rt::{spawn, Arbiter};
use crate::service::Pipeline; use crate::service::Pipeline;
use ntex_util::time::Millis;
use crate::time::{sleep, Sleep}; use crate::time::{sleep, Sleep};
use crate::util::{ use crate::util::{
join_all, ready, select, stream_recv, BoxFuture, Either, Stream as FutStream, join_all, ready, select, stream_recv, BoxFuture, Either, Stream as FutStream,
}; };
use ntex_util::time::Millis;
use super::service::{BoxedServerService, InternalServiceFactory, ServerMessage}; use super::service::{BoxedServerService, InternalServiceFactory, ServerMessage};
use super::{counter::Counter, Token}; use super::{counter::Counter, Token};
@ -378,7 +378,8 @@ enum WorkerState<T> {
} }
impl<T> Future for Worker<T> impl<T> Future for Worker<T>
where T: 'static + Send where
T: 'static + Send,
{ {
type Output = (); type Output = ();
@ -548,7 +549,7 @@ where T: 'static + Send
#[cfg(test)] #[cfg(test)]
mod tests { mod tests {
use std::sync::{Arc, Mutex}; use std::sync::Mutex;
use super::*; use super::*;
use crate::io::Io; use crate::io::Io;
@ -625,8 +626,10 @@ mod tests {
let (sync_tx, _sync_rx) = std::sync::mpsc::channel(); let (sync_tx, _sync_rx) = std::sync::mpsc::channel();
let poll = Arc::new(polling::Poller::new().unwrap()); let poll = Arc::new(polling::Poller::new().unwrap());
let waker = poll.clone(); let waker = poll.clone();
let avail = let avail = WorkerAvailability::new(Box::new(AcceptNotify::new(
WorkerAvailability::new(Box::new(AcceptNotify::new(waker.clone(), sync_tx.clone()))); waker.clone(),
sync_tx.clone(),
)));
let st = Arc::new(Mutex::new(St::Pending)); let st = Arc::new(Mutex::new(St::Pending));
let counter = Arc::new(Mutex::new(0)); let counter = Arc::new(Mutex::new(0));
@ -703,7 +706,8 @@ mod tests {
// force shutdown // force shutdown
let (_tx1, rx1) = unbounded(); let (_tx1, rx1) = unbounded();
let (tx2, rx2) = unbounded(); let (tx2, rx2) = unbounded();
let avail = WorkerAvailability::new(Box::new(AcceptNotify::new(waker, sync_tx.clone()))); let avail =
WorkerAvailability::new(Box::new(AcceptNotify::new(waker, sync_tx.clone())));
let f = SrvFactory { let f = SrvFactory {
st: st.clone(), st: st.clone(),
counter: counter.clone(), counter: counter.clone(),

View file

@ -597,10 +597,7 @@ mod tests {
use crate::service::fn_service; use crate::service::fn_service;
use crate::util::{Bytes, Ready}; use crate::util::{Bytes, Ready};
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::{ use crate::web::{self, middleware::DefaultHeaders, HttpRequest, HttpResponse};
self, middleware::DefaultHeaders, DefaultError, HttpRequest, HttpResponse,
WebRequest,
};
#[crate::rt_test] #[crate::rt_test]
async fn test_default_resource() { async fn test_default_resource() {

View file

@ -681,7 +681,6 @@ mod tests {
use super::*; use super::*;
use crate::http::client::error::{ConnectError, SendRequestError}; use crate::http::client::error::{ConnectError, SendRequestError};
use crate::web::test::TestRequest; use crate::web::test::TestRequest;
use crate::web::DefaultError;
#[test] #[test]
fn test_into_error() { fn test_into_error() {

View file

@ -414,7 +414,6 @@ impl Guard for HostGuard {
#[cfg(test)] #[cfg(test)]
mod tests { mod tests {
use super::*; use super::*;
use crate::http::{header, Method};
use crate::web::test::TestRequest; use crate::web::test::TestRequest;
#[test] #[test]

View file

@ -140,10 +140,8 @@ where
#[cfg(test)] #[cfg(test)]
mod tests { mod tests {
use super::*; use super::*;
use crate::http::header::CONTENT_TYPE;
use crate::service::{IntoService, Pipeline}; use crate::service::{IntoService, Pipeline};
use crate::util::lazy; use crate::util::lazy;
use crate::web::request::WebRequest;
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};

View file

@ -417,7 +417,7 @@ impl<'a> fmt::Display for FormatDisplay<'a> {
mod tests { mod tests {
use super::*; use super::*;
use crate::http::{header, StatusCode}; use crate::http::{header, StatusCode};
use crate::service::{IntoService, Middleware, Pipeline}; use crate::service::{IntoService, Pipeline};
use crate::util::lazy; use crate::util::lazy;
use crate::web::test::{self, TestRequest}; use crate::web::test::{self, TestRequest};
use crate::web::{DefaultError, Error}; use crate::web::{DefaultError, Error};

View file

@ -307,10 +307,10 @@ where
pub(crate) mod tests { pub(crate) mod tests {
use super::*; use super::*;
use crate::http::body::{Body, ResponseBody}; use crate::http::body::{Body, ResponseBody};
use crate::http::header::{HeaderValue, CONTENT_TYPE}; use crate::http::header::CONTENT_TYPE;
use crate::http::{Response as HttpResponse, StatusCode}; use crate::http::Response as HttpResponse;
use crate::web;
use crate::web::test::{init_service, TestRequest}; use crate::web::test::{init_service, TestRequest};
use crate::{util::Bytes, util::BytesMut, web};
fn responder<T: Responder<DefaultError>>(responder: T) -> impl Responder<DefaultError> { fn responder<T: Responder<DefaultError>>(responder: T) -> impl Responder<DefaultError> {
responder responder

View file

@ -282,8 +282,8 @@ pub async fn respond_to<T: Responder<DefaultError>>(
/// } /// }
/// } /// }
/// ///
/// #[test] /// #[ntex::test]
/// fn test_index() { /// async fn test_index() {
/// let req = test::TestRequest::with_header("content-type", "text/plain") /// let req = test::TestRequest::with_header("content-type", "text/plain")
/// .to_http_request(); /// .to_http_request();
/// ///
@ -972,9 +972,8 @@ mod tests {
use std::convert::Infallible; use std::convert::Infallible;
use super::*; use super::*;
use crate::http::header; use crate::http::{header, HttpMessage};
use crate::http::HttpMessage; use crate::web::{self, App};
use crate::web::{self, App, HttpResponse};
#[crate::rt_test] #[crate::rt_test]
async fn test_basics() { async fn test_basics() {

View file

@ -333,7 +333,7 @@ mod tests {
use serde::{Deserialize, Serialize}; use serde::{Deserialize, Serialize};
use super::*; use super::*;
use crate::http::header::{HeaderValue, CONTENT_TYPE}; use crate::http::header::HeaderValue;
use crate::util::Bytes; use crate::util::Bytes;
use crate::web::test::{from_request, respond_to, TestRequest}; use crate::web::test::{from_request, respond_to, TestRequest};

View file

@ -405,8 +405,6 @@ impl Future for HttpMessageBody {
#[cfg(test)] #[cfg(test)]
mod tests { mod tests {
use super::*; use super::*;
use crate::http::header;
use crate::util::Bytes;
use crate::web::test::{from_request, TestRequest}; use crate::web::test::{from_request, TestRequest};
#[crate::rt_test] #[crate::rt_test]

View file

@ -905,6 +905,7 @@ mod tests {
} }
#[crate::rt_test] #[crate::rt_test]
#[allow(clippy::let_underscore_future)]
async fn bearer_auth() { async fn bearer_auth() {
let client = WsClient::build("http://localhost") let client = WsClient::build("http://localhost")
.bearer_auth("someS3cr3tAutht0k3n") .bearer_auth("someS3cr3tAutht0k3n")

View file

@ -217,7 +217,6 @@ impl Parser {
#[cfg(test)] #[cfg(test)]
mod tests { mod tests {
use super::*; use super::*;
use crate::util::Bytes;
struct F { struct F {
finished: bool, finished: bool,

View file

@ -83,7 +83,7 @@ pub fn handshake_response(req: &RequestHead) -> ResponseBuilder {
#[cfg(test)] #[cfg(test)]
mod tests { mod tests {
use super::*; use super::*;
use crate::http::{error::ResponseError, header, test::TestRequest, Method}; use crate::http::{error::ResponseError, test::TestRequest};
#[test] #[test]
fn test_handshake() { fn test_handshake() {

View file

@ -81,9 +81,9 @@ async fn test_openssl_string() {
let tcp = std::net::TcpListener::bind("127.0.0.1:0").unwrap(); let tcp = std::net::TcpListener::bind("127.0.0.1:0").unwrap();
let local_addr = tcp.local_addr().unwrap(); let local_addr = tcp.local_addr().unwrap();
let tcp = Some(tcp); let mut tcp = Some(tcp);
let srv = build_test_server(move |srv| { let srv = build_test_server(move |srv| {
srv.listen("test", tcp.unwrap(), |_| { srv.listen("test", tcp.take().unwrap(), |_| {
chain_factory( chain_factory(
fn_service(|io: Io<_>| async move { fn_service(|io: Io<_>| async move {
let res = io.read_ready().await; let res = io.read_ready().await;

View file

@ -103,7 +103,7 @@ async fn test_expect_continue() {
#[ntex::test] #[ntex::test]
async fn test_chunked_payload() { async fn test_chunked_payload() {
let chunk_sizes = vec![32768, 32, 32768]; let chunk_sizes = [32768, 32, 32768];
let total_size: usize = chunk_sizes.iter().sum(); let total_size: usize = chunk_sizes.iter().sum();
let srv = test_server(|| { let srv = test_server(|| {

View file

@ -1,3 +1,4 @@
#![allow(clippy::let_underscore_future)]
use std::sync::atomic::{AtomicUsize, Ordering::Relaxed}; use std::sync::atomic::{AtomicUsize, Ordering::Relaxed};
use std::{io, io::Read, net, sync::mpsc, sync::Arc, thread, time}; use std::{io, io::Read, net, sync::mpsc, sync::Arc, thread, time};

View file

@ -1,3 +1,4 @@
#![allow(clippy::let_underscore_future)]
use std::{sync::mpsc, thread, time::Duration}; use std::{sync::mpsc, thread, time::Duration};
#[cfg(feature = "openssl")] #[cfg(feature = "openssl")]