diff --git a/ntex-async-std/src/signals.rs b/ntex-async-std/src/signals.rs index 47f5613b..d90135ad 100644 --- a/ntex-async-std/src/signals.rs +++ b/ntex-async-std/src/signals.rs @@ -1,7 +1,7 @@ use std::{cell::RefCell, future::Future, pin::Pin, rc::Rc, task::Context, task::Poll}; thread_local! { - static SRUN: RefCell = RefCell::new(false); + static SRUN: RefCell = const { RefCell::new(false) }; static SHANDLERS: Rc>>> = Default::default(); } diff --git a/ntex-bytes/src/bytes.rs b/ntex-bytes/src/bytes.rs index 52787e77..753cdf5e 100644 --- a/ntex-bytes/src/bytes.rs +++ b/ntex-bytes/src/bytes.rs @@ -4179,7 +4179,11 @@ mod tests { } #[test] - #[allow(clippy::len_zero)] + #[allow( + clippy::len_zero, + clippy::nonminimal_bool, + clippy::unnecessary_fallible_conversions + )] fn bytes() { let mut b = Bytes::from(LONG.to_vec()); b.clear(); @@ -4226,6 +4230,7 @@ mod tests { } #[test] + #[allow(clippy::unnecessary_fallible_conversions)] fn bytes_vec() { let bv = BytesVec::copy_from_slice(LONG); // SharedVec size is 32 diff --git a/ntex-bytes/src/string.rs b/ntex-bytes/src/string.rs index af38ba80..430edb4b 100644 --- a/ntex-bytes/src/string.rs +++ b/ntex-bytes/src/string.rs @@ -371,7 +371,7 @@ mod utf8 { #[cfg(test)] mod test { - use std::borrow::{Borrow, Cow, ToOwned}; + use std::borrow::{Borrow, Cow}; use std::collections::hash_map::DefaultHasher; use std::hash::{Hash, Hasher}; diff --git a/ntex-bytes/tests/test_buf.rs b/ntex-bytes/tests/test_buf.rs index fd02b587..d47ebf59 100644 --- a/ntex-bytes/tests/test_buf.rs +++ b/ntex-bytes/tests/test_buf.rs @@ -1,4 +1,5 @@ #![deny(warnings, rust_2018_idioms)] +#![allow(clippy::unnecessary_mut_passed)] use ntex_bytes::{Buf, Bytes, BytesMut}; diff --git a/ntex-bytes/tests/test_bytes.rs b/ntex-bytes/tests/test_bytes.rs index 2f50513d..c8644a5a 100644 --- a/ntex-bytes/tests/test_bytes.rs +++ b/ntex-bytes/tests/test_bytes.rs @@ -1,3 +1,4 @@ +#![allow(clippy::op_ref, clippy::let_underscore_future)] use std::{borrow::Borrow, borrow::BorrowMut, task::Poll}; use ntex_bytes::{Buf, BufMut, Bytes, BytesMut, BytesVec, Pool, PoolId, PoolRef}; diff --git a/ntex-connect/src/openssl.rs b/ntex-connect/src/openssl.rs index 9d51bbe0..c4ec608d 100644 --- a/ntex-connect/src/openssl.rs +++ b/ntex-connect/src/openssl.rs @@ -124,7 +124,6 @@ impl Service> for Connector { #[cfg(test)] mod tests { use super::*; - use ntex_service::ServiceFactory; #[ntex::test] async fn test_openssl_connect() { diff --git a/ntex-connect/src/rustls.rs b/ntex-connect/src/rustls.rs index 60628151..6d763abe 100644 --- a/ntex-connect/src/rustls.rs +++ b/ntex-connect/src/rustls.rs @@ -126,11 +126,9 @@ impl Service> for Connector { #[cfg(test)] mod tests { - use std::sync::Arc; use tls_rustls::{OwnedTrustAnchor, RootCertStore}; use super::*; - use ntex_service::ServiceFactory; use ntex_util::future::lazy; #[ntex::test] diff --git a/ntex-http/src/map.rs b/ntex-http/src/map.rs index b52bfbca..53124b55 100644 --- a/ntex-http/src/map.rs +++ b/ntex-http/src/map.rs @@ -579,7 +579,7 @@ mod tests { } #[test] - #[allow(clippy::needless_borrow)] + #[allow(clippy::needless_borrow, clippy::needless_borrows_for_generic_args)] fn test_basics() { let m = HeaderMap::default(); assert!(m.is_empty()); diff --git a/ntex-http/src/value.rs b/ntex-http/src/value.rs index 9d3968b5..0c6cceea 100644 --- a/ntex-http/src/value.rs +++ b/ntex-http/src/value.rs @@ -85,6 +85,7 @@ impl HeaderValue { let mut i = 0; while i < bytes.len() { if !is_visible_ascii(bytes[i]) { + #[allow(clippy::out_of_bounds_indexing)] ([] as [u8; 0])[0]; // Invalid header value } i += 1; diff --git a/ntex-io/src/dispatcher.rs b/ntex-io/src/dispatcher.rs index 77dd3aae..84f40c12 100644 --- a/ntex-io/src/dispatcher.rs +++ b/ntex-io/src/dispatcher.rs @@ -1,4 +1,5 @@ //! Framed transport dispatcher +#![allow(clippy::let_underscore_future)] use std::{cell::Cell, future, pin::Pin, rc::Rc, task::Context, task::Poll}; use ntex_bytes::Pool; @@ -341,7 +342,7 @@ where // call service let shared = slf.shared.clone(); shared.inflight.set(shared.inflight.get() + 1); - spawn(async move { + let _ = spawn(async move { let result = shared.service.call(item).await; shared.handle_result(result, &shared.io); }); @@ -365,7 +366,7 @@ where // call service let shared = slf.shared.clone(); shared.inflight.set(shared.inflight.get() + 1); - spawn(async move { + let _ = spawn(async move { let result = shared.service.call(item).await; shared.handle_result(result, &shared.io); }); @@ -595,7 +596,7 @@ mod tests { use ntex_bytes::{Bytes, BytesMut, PoolId, PoolRef}; use ntex_codec::BytesCodec; use ntex_service::ServiceCtx; - use ntex_util::{time::sleep, time::Millis, time::Seconds}; + use ntex_util::{time::sleep, time::Millis}; use super::*; use crate::{io::Flags, testing::IoTest, Io, IoRef, IoStream}; diff --git a/ntex-io/src/io.rs b/ntex-io/src/io.rs index 937bbe8c..eaa20f0a 100644 --- a/ntex-io/src/io.rs +++ b/ntex-io/src/io.rs @@ -932,7 +932,7 @@ mod tests { use ntex_codec::BytesCodec; 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 TEXT: &str = "GET /test HTTP/1\r\n\r\n"; diff --git a/ntex-io/src/ioref.rs b/ntex-io/src/ioref.rs index 7d33a952..f553d62e 100644 --- a/ntex-io/src/ioref.rs +++ b/ntex-io/src/ioref.rs @@ -119,18 +119,15 @@ impl IoRef { }) // .with_write_buf() could return io::Error>, // in that case mark io as failed - .map_or_else( - |err| { - log::trace!( - "{}: Got io error while encoding, error: {:?}", - self.tag(), - err - ); - self.0.io_stopped(Some(err)); - Ok(()) - }, - |item| item, - ) + .unwrap_or_else(|err| { + log::trace!( + "{}: Got io error while encoding, error: {:?}", + self.tag(), + err + ); + self.0.io_stopped(Some(err)); + Ok(()) + }) } else { log::trace!("{}: Io is closed/closing, skip frame encoding", self.tag()); Ok(()) @@ -318,7 +315,7 @@ mod tests { use ntex_util::time::{sleep, Millis}; 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 TEXT: &str = "GET /test HTTP/1\r\n\r\n"; diff --git a/ntex-io/src/testing.rs b/ntex-io/src/testing.rs index 590d6568..604b3627 100644 --- a/ntex-io/src/testing.rs +++ b/ntex-io/src/testing.rs @@ -1,4 +1,5 @@ //! utilities and helpers for testing +#![allow(clippy::let_underscore_future)] use std::future::{poll_fn, Future}; use std::sync::{Arc, Mutex}; use std::task::{ready, Context, Poll, Waker}; @@ -355,11 +356,11 @@ impl IoStream for IoTest { fn start(self, read: ReadContext, write: WriteContext) -> Option> { let io = Rc::new(self); - ntex_util::spawn(ReadTask { + let _ = ntex_util::spawn(ReadTask { io: io.clone(), state: read, }); - ntex_util::spawn(WriteTask { + let _ = ntex_util::spawn(WriteTask { io: io.clone(), state: write, st: IoWriteState::Processing(None), diff --git a/ntex-io/src/timer.rs b/ntex-io/src/timer.rs index 5af6079a..b30f6182 100644 --- a/ntex-io/src/timer.rs +++ b/ntex-io/src/timer.rs @@ -127,7 +127,8 @@ pub(crate) fn register(timeout: Seconds, io: &IoRef) -> TimerHandle { if !timer.running.get() { timer.running.set(true); - spawn(async move { + #[allow(clippy::let_underscore_future)] + let _ = spawn(async move { let guard = TimerGuard; loop { sleep(SEC).await; diff --git a/ntex-router/src/de.rs b/ntex-router/src/de.rs index 681fcf05..38aae0a5 100644 --- a/ntex-router/src/de.rs +++ b/ntex-router/src/de.rs @@ -491,11 +491,10 @@ impl<'de> de::VariantAccess<'de> for UnitVariant { #[cfg(test)] mod tests { - use serde::de; use serde_derive::Deserialize; use super::*; - use crate::path::{Path, PathItem}; + use crate::path::PathItem; #[derive(Deserialize)] struct MyStruct { diff --git a/ntex-router/src/resource.rs b/ntex-router/src/resource.rs index 6dff24df..5fe13c07 100644 --- a/ntex-router/src/resource.rs +++ b/ntex-router/src/resource.rs @@ -754,6 +754,7 @@ mod tests { } #[test] + #[allow(clippy::needless_borrows_for_generic_args)] fn test_static_tail() { let re = ResourceDef::new("/*".to_string()); let tree = Tree::new(&re, 1); diff --git a/ntex-rt/src/arbiter.rs b/ntex-rt/src/arbiter.rs index a7f0249a..f81a49be 100644 --- a/ntex-rt/src/arbiter.rs +++ b/ntex-rt/src/arbiter.rs @@ -1,3 +1,4 @@ +#![allow(clippy::let_underscore_future)] use std::any::{Any, TypeId}; use std::sync::atomic::{AtomicUsize, Ordering}; use std::task::{Context, Poll}; @@ -9,7 +10,7 @@ use futures_core::stream::Stream; use crate::system::System; thread_local!( - static ADDR: RefCell> = RefCell::new(None); + static ADDR: RefCell> = const { RefCell::new(None) }; static STORAGE: RefCell>> = RefCell::new(HashMap::new()); ); @@ -103,7 +104,7 @@ impl Arbiter { crate::block_on(async move { // start arbiter controller - crate::spawn(ArbiterController { + let _ = crate::spawn(ArbiterController { stop: Some(stop), rx: Box::pin(arb_rx), }); @@ -268,7 +269,7 @@ impl Future for ArbiterController { return Poll::Ready(()); } ArbiterCommand::Execute(fut) => { - crate::spawn(fut); + let _ = crate::spawn(fut); } ArbiterCommand::ExecuteFn(f) => { f.call_box(); diff --git a/ntex-rt/src/builder.rs b/ntex-rt/src/builder.rs index a49a1722..55db7bd0 100644 --- a/ntex-rt/src/builder.rs +++ b/ntex-rt/src/builder.rs @@ -1,3 +1,4 @@ +#![allow(clippy::let_underscore_future)] use std::{cell::RefCell, future::Future, io, rc::Rc}; use async_channel::unbounded; @@ -159,8 +160,8 @@ where let result = Rc::new(RefCell::new(None)); let result_inner = result.clone(); crate::block_on(Box::pin(async move { - crate::spawn(arb); - crate::spawn(arb_controller); + let _ = crate::spawn(arb); + let _ = crate::spawn(arb_controller); if let Err(e) = f() { *result_inner.borrow_mut() = Some(Err(e)); } else { diff --git a/ntex-rt/src/system.rs b/ntex-rt/src/system.rs index 61bd20ff..dc2fddec 100644 --- a/ntex-rt/src/system.rs +++ b/ntex-rt/src/system.rs @@ -16,7 +16,7 @@ pub struct System { } thread_local!( - static CURRENT: RefCell> = RefCell::new(None); + static CURRENT: RefCell> = const { RefCell::new(None) }; ); impl System { diff --git a/ntex-service/src/apply.rs b/ntex-service/src/apply.rs index 71733eae..6802a34e 100644 --- a/ntex-service/src/apply.rs +++ b/ntex-service/src/apply.rs @@ -203,7 +203,7 @@ mod tests { use std::task::Poll; use super::*; - use crate::{chain, chain_factory, Service, ServiceCtx}; + use crate::{chain, chain_factory}; #[derive(Clone, Debug)] struct Srv; diff --git a/ntex-service/src/ctx.rs b/ntex-service/src/ctx.rs index 9baef377..4c30e7d9 100644 --- a/ntex-service/src/ctx.rs +++ b/ntex-service/src/ctx.rs @@ -193,10 +193,10 @@ impl<'a, S> fmt::Debug for ServiceCtx<'a, S> { #[cfg(test)] mod tests { - use ntex_util::future::lazy; - use ntex_util::{channel::condition, time}; - use std::task::{Context, Poll}; - use std::{cell::Cell, cell::RefCell, future::poll_fn, rc::Rc}; + use std::task::Context; + use std::{cell::Cell, cell::RefCell}; + + use ntex_util::{channel::condition, future::lazy, time}; use super::*; use crate::Pipeline; @@ -218,6 +218,7 @@ mod tests { ctx: ServiceCtx<'_, Self>, ) -> Result { format!("{:?}", ctx); + #[allow(clippy::clone_on_copy)] let _ = ctx.clone(); Ok(req) } diff --git a/ntex-service/src/fn_service.rs b/ntex-service/src/fn_service.rs index ed0d44e9..6ff3feb5 100644 --- a/ntex-service/src/fn_service.rs +++ b/ntex-service/src/fn_service.rs @@ -389,7 +389,7 @@ mod tests { use std::task::Poll; use super::*; - use crate::{Pipeline, ServiceFactory}; + use crate::Pipeline; #[ntex::test] async fn test_fn_service() { diff --git a/ntex-service/src/fn_shutdown.rs b/ntex-service/src/fn_shutdown.rs index a3945a32..8f68b82b 100644 --- a/ntex-service/src/fn_shutdown.rs +++ b/ntex-service/src/fn_shutdown.rs @@ -72,7 +72,7 @@ where #[cfg(test)] mod tests { use ntex_util::future::lazy; - use std::{rc::Rc, task::Poll}; + use std::rc::Rc; use crate::{chain, fn_service, Pipeline}; diff --git a/ntex-service/src/map_config.rs b/ntex-service/src/map_config.rs index 822f0014..dcac031d 100644 --- a/ntex-service/src/map_config.rs +++ b/ntex-service/src/map_config.rs @@ -119,7 +119,7 @@ mod tests { use std::{cell::Cell, rc::Rc}; use super::*; - use crate::{fn_service, ServiceFactory}; + use crate::fn_service; #[ntex::test] async fn test_map_config() { diff --git a/ntex-service/src/map_err.rs b/ntex-service/src/map_err.rs index 0e4b8aeb..a5d6b905 100644 --- a/ntex-service/src/map_err.rs +++ b/ntex-service/src/map_err.rs @@ -161,7 +161,7 @@ mod tests { use ntex_util::future::{lazy, Ready}; use super::*; - use crate::{fn_factory, Pipeline, Service, ServiceCtx, ServiceFactory}; + use crate::{fn_factory, Pipeline}; #[derive(Debug, Clone)] struct Srv(bool); diff --git a/ntex-service/src/middleware.rs b/ntex-service/src/middleware.rs index 39592c38..06981b67 100644 --- a/ntex-service/src/middleware.rs +++ b/ntex-service/src/middleware.rs @@ -187,7 +187,7 @@ mod tests { use std::task::{Context, Poll}; use super::*; - use crate::{fn_service, Pipeline, Service, ServiceCtx, ServiceFactory}; + use crate::{fn_service, Pipeline, ServiceCtx}; #[derive(Debug, Clone)] struct Tr(PhantomData); diff --git a/ntex-tokio/src/signals.rs b/ntex-tokio/src/signals.rs index b4ecfdab..87ff229d 100644 --- a/ntex-tokio/src/signals.rs +++ b/ntex-tokio/src/signals.rs @@ -6,7 +6,7 @@ use tokio::sync::oneshot; use tokio::task::spawn_local; thread_local! { - static SRUN: RefCell = RefCell::new(false); + static SRUN: RefCell = const { RefCell::new(false) }; static SHANDLERS: Rc>>> = Default::default(); } diff --git a/ntex-util/src/channel/mpsc.rs b/ntex-util/src/channel/mpsc.rs index e4b16b3e..b5cbc865 100644 --- a/ntex-util/src/channel/mpsc.rs +++ b/ntex-util/src/channel/mpsc.rs @@ -252,8 +252,7 @@ impl SendError { #[cfg(test)] mod tests { use super::*; - use crate::{future::lazy, future::stream_recv, Stream}; - use futures_sink::Sink; + use crate::{future::lazy, future::stream_recv}; #[ntex_macros::rt_test2] async fn test_mpsc() { diff --git a/ntex-util/src/services/buffer.rs b/ntex-util/src/services/buffer.rs index 91bb20ce..8dbd75d9 100644 --- a/ntex-util/src/services/buffer.rs +++ b/ntex-util/src/services/buffer.rs @@ -287,8 +287,8 @@ where #[cfg(test)] mod tests { - use ntex_service::{apply, fn_factory, Pipeline, Service, ServiceFactory}; - use std::{rc::Rc, task::Context, task::Poll, time::Duration}; + use ntex_service::{apply, fn_factory, Pipeline, ServiceFactory}; + use std::{rc::Rc, time::Duration}; use super::*; use crate::future::lazy; diff --git a/ntex-util/src/services/extensions.rs b/ntex-util/src/services/extensions.rs index 57ba572d..fa8d5ae1 100644 --- a/ntex-util/src/services/extensions.rs +++ b/ntex-util/src/services/extensions.rs @@ -1,4 +1,4 @@ -use std::{any::Any, any::TypeId, fmt, iter::Extend}; +use std::{any::Any, any::TypeId, fmt}; #[derive(Default)] /// A type map of request extensions. diff --git a/ntex-util/src/services/inflight.rs b/ntex-util/src/services/inflight.rs index 6d781f93..c6fff000 100644 --- a/ntex-util/src/services/inflight.rs +++ b/ntex-util/src/services/inflight.rs @@ -90,8 +90,8 @@ where #[cfg(test)] mod tests { - use ntex_service::{apply, fn_factory, Pipeline, Service, ServiceCtx, ServiceFactory}; - use std::{cell::RefCell, task::Poll, time::Duration}; + use ntex_service::{apply, fn_factory, Pipeline, ServiceFactory}; + use std::{cell::RefCell, time::Duration}; use super::*; use crate::{channel::oneshot, future::lazy}; diff --git a/ntex-util/src/services/keepalive.rs b/ntex-util/src/services/keepalive.rs index 7b789828..d363f19f 100644 --- a/ntex-util/src/services/keepalive.rs +++ b/ntex-util/src/services/keepalive.rs @@ -138,8 +138,6 @@ where #[cfg(test)] mod tests { - use ntex_service::ServiceFactory; - use super::*; use crate::future::lazy; diff --git a/ntex-util/src/services/onerequest.rs b/ntex-util/src/services/onerequest.rs index 7f2537f6..011b5a22 100644 --- a/ntex-util/src/services/onerequest.rs +++ b/ntex-util/src/services/onerequest.rs @@ -81,8 +81,8 @@ where #[cfg(test)] mod tests { - use ntex_service::{apply, fn_factory, Pipeline, Service, ServiceCtx, ServiceFactory}; - use std::{cell::RefCell, task::Poll, time::Duration}; + use ntex_service::{apply, fn_factory, Pipeline, ServiceFactory}; + use std::{cell::RefCell, time::Duration}; use super::*; use crate::{channel::oneshot, future::lazy}; diff --git a/ntex-util/src/services/timeout.rs b/ntex-util/src/services/timeout.rs index 1855b8ce..53404c25 100644 --- a/ntex-util/src/services/timeout.rs +++ b/ntex-util/src/services/timeout.rs @@ -147,9 +147,9 @@ where #[cfg(test)] 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 crate::future::lazy; diff --git a/ntex-util/src/services/variant.rs b/ntex-util/src/services/variant.rs index 02235c10..021749f7 100644 --- a/ntex-util/src/services/variant.rs +++ b/ntex-util/src/services/variant.rs @@ -232,8 +232,7 @@ variant_impl_and!(VariantFactory7, VariantFactory8, V8, V8R, v8, (V2, V3, V4, V5 #[cfg(test)] mod tests { - use ntex_service::{fn_factory, Service, ServiceFactory}; - use std::task::{Context, Poll}; + use ntex_service::fn_factory; use super::*; use crate::future::lazy; diff --git a/ntex-util/src/time/mod.rs b/ntex-util/src/time/mod.rs index 5dbc1525..34f6c4b9 100644 --- a/ntex-util/src/time/mod.rs +++ b/ntex-util/src/time/mod.rs @@ -339,6 +339,7 @@ impl crate::Stream for Interval { } #[cfg(test)] +#[allow(clippy::let_underscore_future)] mod tests { use futures_util::StreamExt; use std::time; diff --git a/ntex-util/src/time/wheel.rs b/ntex-util/src/time/wheel.rs index 93453956..b22538f3 100644 --- a/ntex-util/src/time/wheel.rs +++ b/ntex-util/src/time/wheel.rs @@ -1,7 +1,7 @@ //! Time wheel based timer service. //! //! Inspired by linux kernel timers system -#![allow(arithmetic_overflow)] +#![allow(arithmetic_overflow, clippy::let_underscore_future)] use std::cell::{Cell, RefCell}; use std::time::{Duration, Instant, SystemTime}; 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 = 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.inner.borrow_mut().lowres_driver_sleep = Delay::new(LOWRES_RESOLUTION); - crate::spawn(LowresTimerDriver(timer)); + let _ = crate::spawn(LowresTimerDriver(timer)); } } diff --git a/ntex/src/http/client/pool.rs b/ntex/src/http/client/pool.rs index 43789b1b..96209755 100644 --- a/ntex/src/http/client/pool.rs +++ b/ntex/src/http/client/pool.rs @@ -388,8 +388,9 @@ where } pin_project_lite::pin_project! { - struct OpenConnection> - where T: 'static + struct OpenConnection + where T: Service, + T: 'static { key: Key, #[pin] @@ -610,11 +611,9 @@ impl Drop for Acquired { #[cfg(test)] mod tests { - use std::{cell::RefCell, rc::Rc}; - use super::*; 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] async fn test_basics() { diff --git a/ntex/src/http/client/request.rs b/ntex/src/http/client/request.rs index 64487b84..d1bf2083 100644 --- a/ntex/src/http/client/request.rs +++ b/ntex/src/http/client/request.rs @@ -583,6 +583,7 @@ mod tests { } #[crate::rt_test] + #[allow(clippy::let_underscore_future)] async fn test_basics() { let mut req = Client::new() .put("/") diff --git a/ntex/src/http/error.rs b/ntex/src/http/error.rs index f13552bf..54d207f3 100644 --- a/ntex/src/http/error.rs +++ b/ntex/src/http/error.rs @@ -238,8 +238,7 @@ impl From> for PayloadError { #[cfg(test)] mod tests { use super::*; - use ntex_http::{Error as HttpError, StatusCode}; - use std::io; + use ntex_http::Error as HttpError; #[test] fn test_into_response() { diff --git a/ntex/src/http/h1/codec.rs b/ntex/src/http/h1/codec.rs index 35c8cc56..8a9e431f 100644 --- a/ntex/src/http/h1/codec.rs +++ b/ntex/src/http/h1/codec.rs @@ -197,8 +197,8 @@ impl Encoder for Codec { #[cfg(test)] mod tests { use super::*; - use crate::http::{h1::PayloadItem, HttpMessage, Method}; - use crate::util::{Bytes, BytesMut}; + use crate::http::{h1::PayloadItem, HttpMessage}; + use crate::util::Bytes; #[test] fn test_http_request_chunked_payload_and_next_message() { diff --git a/ntex/src/http/h1/decoder.rs b/ntex/src/http/h1/decoder.rs index 16160337..a8dc4a13 100644 --- a/ntex/src/http/h1/decoder.rs +++ b/ntex/src/http/h1/decoder.rs @@ -740,9 +740,8 @@ fn uninit_array() -> [mem::MaybeUninit; LEN] { #[cfg(test)] mod tests { use super::*; - use crate::http::header::{HeaderName, SET_COOKIE}; - use crate::http::{HttpMessage, Method, Version}; - use crate::util::{Bytes, BytesMut}; + use crate::http::header::SET_COOKIE; + use crate::http::HttpMessage; impl PayloadType { fn unwrap(self) -> PayloadDecoder { diff --git a/ntex/src/http/h1/dispatcher.rs b/ntex/src/http/h1/dispatcher.rs index 92a3e094..98a1bf6b 100644 --- a/ntex/src/http/h1/dispatcher.rs +++ b/ntex/src/http/h1/dispatcher.rs @@ -838,19 +838,19 @@ where #[cfg(test)] mod tests { 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 rand::Rng; use super::*; - use crate::http::config::{DispatcherConfig, ServiceConfig}; + use crate::http::config::ServiceConfig; 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::service::{fn_service, IntoService}; 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; diff --git a/ntex/src/http/h1/service.rs b/ntex/src/http/h1/service.rs index a176e762..986b0967 100644 --- a/ntex/src/http/h1/service.rs +++ b/ntex/src/http/h1/service.rs @@ -83,8 +83,6 @@ mod openssl { #[cfg(feature = "rustls")] mod rustls { - use std::fmt; - use ntex_tls::rustls::{TlsAcceptor, TlsServerFilter}; use tls_rustls::ServerConfig; diff --git a/ntex/src/http/response.rs b/ntex/src/http/response.rs index 9e36ceb1..c2706a0c 100644 --- a/ntex/src/http/response.rs +++ b/ntex/src/http/response.rs @@ -808,8 +808,7 @@ impl From for Response { #[cfg(test)] mod tests { use super::*; - use crate::http::body::Body; - use crate::http::header::{HeaderValue, CONTENT_TYPE, COOKIE}; + use crate::http::header::{CONTENT_TYPE, COOKIE}; #[test] fn test_debug() { diff --git a/ntex/src/server/worker.rs b/ntex/src/server/worker.rs index 64476f08..637733ed 100644 --- a/ntex/src/server/worker.rs +++ b/ntex/src/server/worker.rs @@ -9,6 +9,7 @@ use crate::time::{sleep, Millis, Sleep}; use crate::util::{ join_all, ready, select, stream_recv, BoxFuture, Either, Stream as FutStream, }; +use ntex_util::time::Millis; use super::accept::{AcceptNotify, Command}; use super::service::{BoxedServerService, InternalServiceFactory, ServerMessage}; @@ -509,7 +510,7 @@ impl Future for Worker { #[cfg(test)] mod tests { - use std::sync::{Arc, Mutex}; + use std::sync::Mutex; use super::*; use crate::io::Io; diff --git a/ntex/src/web/app.rs b/ntex/src/web/app.rs index 8f5b7830..f939220f 100644 --- a/ntex/src/web/app.rs +++ b/ntex/src/web/app.rs @@ -597,10 +597,7 @@ mod tests { use crate::service::fn_service; use crate::util::{Bytes, Ready}; use crate::web::test::{call_service, init_service, read_body, TestRequest}; - use crate::web::{ - self, middleware::DefaultHeaders, DefaultError, HttpRequest, HttpResponse, - WebRequest, - }; + use crate::web::{self, middleware::DefaultHeaders, HttpRequest, HttpResponse}; #[crate::rt_test] async fn test_default_resource() { diff --git a/ntex/src/web/error.rs b/ntex/src/web/error.rs index f9012373..f6eabc47 100644 --- a/ntex/src/web/error.rs +++ b/ntex/src/web/error.rs @@ -681,7 +681,6 @@ mod tests { use super::*; use crate::http::client::error::{ConnectError, SendRequestError}; use crate::web::test::TestRequest; - use crate::web::DefaultError; #[test] fn test_into_error() { diff --git a/ntex/src/web/guard.rs b/ntex/src/web/guard.rs index 1fca9137..c81ac371 100644 --- a/ntex/src/web/guard.rs +++ b/ntex/src/web/guard.rs @@ -414,7 +414,6 @@ impl Guard for HostGuard { #[cfg(test)] mod tests { use super::*; - use crate::http::{header, Method}; use crate::web::test::TestRequest; #[test] diff --git a/ntex/src/web/middleware/defaultheaders.rs b/ntex/src/web/middleware/defaultheaders.rs index 01a895d9..2e9d9ae9 100644 --- a/ntex/src/web/middleware/defaultheaders.rs +++ b/ntex/src/web/middleware/defaultheaders.rs @@ -140,10 +140,8 @@ where #[cfg(test)] mod tests { use super::*; - use crate::http::header::CONTENT_TYPE; use crate::service::{IntoService, Pipeline}; use crate::util::lazy; - use crate::web::request::WebRequest; use crate::web::test::{ok_service, TestRequest}; use crate::web::{DefaultError, Error, HttpResponse}; diff --git a/ntex/src/web/middleware/logger.rs b/ntex/src/web/middleware/logger.rs index 3880f6e0..514b9dbd 100644 --- a/ntex/src/web/middleware/logger.rs +++ b/ntex/src/web/middleware/logger.rs @@ -417,7 +417,7 @@ impl<'a> fmt::Display for FormatDisplay<'a> { mod tests { use super::*; use crate::http::{header, StatusCode}; - use crate::service::{IntoService, Middleware, Pipeline}; + use crate::service::{IntoService, Pipeline}; use crate::util::lazy; use crate::web::test::{self, TestRequest}; use crate::web::{DefaultError, Error}; diff --git a/ntex/src/web/responder.rs b/ntex/src/web/responder.rs index 4e31fdce..b42ee506 100644 --- a/ntex/src/web/responder.rs +++ b/ntex/src/web/responder.rs @@ -307,10 +307,10 @@ where pub(crate) mod tests { use super::*; use crate::http::body::{Body, ResponseBody}; - use crate::http::header::{HeaderValue, CONTENT_TYPE}; - use crate::http::{Response as HttpResponse, StatusCode}; + use crate::http::header::CONTENT_TYPE; + use crate::http::Response as HttpResponse; + use crate::web; use crate::web::test::{init_service, TestRequest}; - use crate::{util::Bytes, util::BytesMut, web}; fn responder>(responder: T) -> impl Responder { responder diff --git a/ntex/src/web/test.rs b/ntex/src/web/test.rs index ad59f1d3..5c7c0d46 100644 --- a/ntex/src/web/test.rs +++ b/ntex/src/web/test.rs @@ -282,8 +282,8 @@ pub async fn respond_to>( /// } /// } /// -/// #[test] -/// fn test_index() { +/// #[ntex::test] +/// async fn test_index() { /// let req = test::TestRequest::with_header("content-type", "text/plain") /// .to_http_request(); /// @@ -972,9 +972,8 @@ mod tests { use std::convert::Infallible; use super::*; - use crate::http::header; - use crate::http::HttpMessage; - use crate::web::{self, App, HttpResponse}; + use crate::http::{header, HttpMessage}; + use crate::web::{self, App}; #[crate::rt_test] async fn test_basics() { diff --git a/ntex/src/web/types/form.rs b/ntex/src/web/types/form.rs index dba40d62..5605aa7f 100644 --- a/ntex/src/web/types/form.rs +++ b/ntex/src/web/types/form.rs @@ -333,7 +333,7 @@ mod tests { use serde::{Deserialize, Serialize}; use super::*; - use crate::http::header::{HeaderValue, CONTENT_TYPE}; + use crate::http::header::HeaderValue; use crate::util::Bytes; use crate::web::test::{from_request, respond_to, TestRequest}; diff --git a/ntex/src/web/types/payload.rs b/ntex/src/web/types/payload.rs index 04339b08..949c74c4 100644 --- a/ntex/src/web/types/payload.rs +++ b/ntex/src/web/types/payload.rs @@ -405,8 +405,6 @@ impl Future for HttpMessageBody { #[cfg(test)] mod tests { use super::*; - use crate::http::header; - use crate::util::Bytes; use crate::web::test::{from_request, TestRequest}; #[crate::rt_test] diff --git a/ntex/src/ws/client.rs b/ntex/src/ws/client.rs index 672cc062..f047fb2c 100644 --- a/ntex/src/ws/client.rs +++ b/ntex/src/ws/client.rs @@ -905,6 +905,7 @@ mod tests { } #[crate::rt_test] + #[allow(clippy::let_underscore_future)] async fn bearer_auth() { let client = WsClient::build("http://localhost") .bearer_auth("someS3cr3tAutht0k3n") diff --git a/ntex/src/ws/frame.rs b/ntex/src/ws/frame.rs index 723b88af..17a80d63 100644 --- a/ntex/src/ws/frame.rs +++ b/ntex/src/ws/frame.rs @@ -217,7 +217,6 @@ impl Parser { #[cfg(test)] mod tests { use super::*; - use crate::util::Bytes; struct F { finished: bool, diff --git a/ntex/src/ws/handshake.rs b/ntex/src/ws/handshake.rs index 24666433..3df32599 100644 --- a/ntex/src/ws/handshake.rs +++ b/ntex/src/ws/handshake.rs @@ -83,7 +83,7 @@ pub fn handshake_response(req: &RequestHead) -> ResponseBuilder { #[cfg(test)] mod tests { use super::*; - use crate::http::{error::ResponseError, header, test::TestRequest, Method}; + use crate::http::{error::ResponseError, test::TestRequest}; #[test] fn test_handshake() { diff --git a/ntex/tests/connect.rs b/ntex/tests/connect.rs index c7894159..f68640ef 100644 --- a/ntex/tests/connect.rs +++ b/ntex/tests/connect.rs @@ -81,9 +81,9 @@ async fn test_openssl_string() { let tcp = std::net::TcpListener::bind("127.0.0.1:0").unwrap(); let local_addr = tcp.local_addr().unwrap(); - let tcp = Some(tcp); + let mut tcp = Some(tcp); let srv = build_test_server(move |srv| { - srv.listen("test", tcp.unwrap(), |_| { + srv.listen("test", tcp.take().unwrap(), |_| { chain_factory( fn_service(|io: Io<_>| async move { let res = io.read_ready().await; diff --git a/ntex/tests/http_server.rs b/ntex/tests/http_server.rs index abaad8a7..433a968d 100644 --- a/ntex/tests/http_server.rs +++ b/ntex/tests/http_server.rs @@ -103,7 +103,7 @@ async fn test_expect_continue() { #[ntex::test] 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 srv = test_server(|| { diff --git a/ntex/tests/server.rs b/ntex/tests/server.rs index 9e2e32de..d19bd1e9 100644 --- a/ntex/tests/server.rs +++ b/ntex/tests/server.rs @@ -1,3 +1,4 @@ +#![allow(clippy::let_underscore_future)] use std::sync::atomic::{AtomicUsize, Ordering::Relaxed}; use std::{io, io::Read, net, sync::mpsc, sync::Arc, thread, time}; diff --git a/ntex/tests/web_httpserver.rs b/ntex/tests/web_httpserver.rs index d5933a82..09769faf 100644 --- a/ntex/tests/web_httpserver.rs +++ b/ntex/tests/web_httpserver.rs @@ -1,3 +1,4 @@ +#![allow(clippy::let_underscore_future)] use std::{sync::mpsc, thread, time::Duration}; #[cfg(feature = "openssl")]