rustmax::std::marker

Trait Send

1.0.0 · Source
pub unsafe auto trait Send { }
Expand description

Types that can be transferred across thread boundaries.

This trait is automatically implemented when the compiler determines it’s appropriate.

An example of a non-Send type is the reference-counting pointer rc::Rc. If two threads attempt to clone Rcs that point to the same reference-counted value, they might try to update the reference count at the same time, which is undefined behavior because Rc doesn’t use atomic operations. Its cousin sync::Arc does use atomic operations (incurring some overhead) and thus is Send.

See the Nomicon and the Sync trait for more details.

Implementors§

1.29.0 · Source§

impl !Send for rustmax::proc_macro::TokenTree

Source§

impl !Send for ExpandError

1.29.0 · Source§

impl !Send for rustmax::proc_macro::Group

1.15.0 · Source§

impl !Send for rustmax::proc_macro::LexError

1.29.0 · Source§

impl !Send for rustmax::proc_macro::Punct

1.29.0 · Source§

impl !Send for rustmax::proc_macro::Span

1.15.0 · Source§

impl !Send for rustmax::proc_macro::TokenStream

1.26.0 · Source§

impl !Send for Args

1.26.0 · Source§

impl !Send for ArgsOs

1.0.0 · Source§

impl !Send for Arguments<'_>

Source§

impl !Send for LocalWaker

Source§

impl Send for atomic_waker::AtomicWaker

Source§

impl Send for libloading::os::unix::Library

Source§

impl Send for libloading::safe::Library

Source§

impl Send for Asn1BitString

Source§

impl Send for Asn1BitStringRef

Source§

impl Send for Asn1Enumerated

Source§

impl Send for Asn1EnumeratedRef

Source§

impl Send for Asn1GeneralizedTime

Source§

impl Send for Asn1GeneralizedTimeRef

Source§

impl Send for Asn1Integer

Source§

impl Send for Asn1IntegerRef

Source§

impl Send for Asn1Object

Source§

impl Send for Asn1ObjectRef

Source§

impl Send for Asn1OctetString

Source§

impl Send for Asn1OctetStringRef

Source§

impl Send for Asn1String

Source§

impl Send for Asn1StringRef

Source§

impl Send for Asn1Time

Source§

impl Send for Asn1TimeRef

Source§

impl Send for BigNum

Source§

impl Send for BigNumContext

Source§

impl Send for BigNumContextRef

Source§

impl Send for BigNumRef

Source§

impl Send for openssl::cipher::Cipher

Source§

impl Send for CipherRef

Source§

impl Send for CipherCtx

Source§

impl Send for CipherCtxRef

Source§

impl Send for CmsContentInfo

Source§

impl Send for CmsContentInfoRef

Source§

impl Send for Conf

Source§

impl Send for ConfRef

Source§

impl Send for Deriver<'_>

Source§

impl Send for DsaSig

Source§

impl Send for DsaSigRef

Source§

impl Send for EcGroup

Source§

impl Send for EcGroupRef

Source§

impl Send for EcPoint

Source§

impl Send for EcPointRef

Source§

impl Send for EcdsaSig

Source§

impl Send for EcdsaSigRef

Source§

impl Send for Decrypter<'_>

Source§

impl Send for Encrypter<'_>

Source§

impl Send for openssl::error::Error

Source§

impl Send for openssl::hash::Hasher

Source§

impl Send for MessageDigest

Source§

impl Send for LibCtx

Source§

impl Send for LibCtxRef

Source§

impl Send for Md

Source§

impl Send for MdRef

Source§

impl Send for MdCtx

Source§

impl Send for MdCtxRef

Source§

impl Send for OcspBasicResponse

Source§

impl Send for OcspBasicResponseRef

Source§

impl Send for OcspCertId

Source§

impl Send for OcspCertIdRef

Source§

impl Send for OcspOneReq

Source§

impl Send for OcspOneReqRef

Source§

impl Send for OcspRequest

Source§

impl Send for OcspRequestRef

Source§

impl Send for OcspResponse

Source§

impl Send for OcspResponseRef

Source§

impl Send for Pkcs7

Source§

impl Send for Pkcs7Ref

Source§

impl Send for Pkcs7Signed

Source§

impl Send for Pkcs7SignedRef

Source§

impl Send for Pkcs7SignerInfo

Source§

impl Send for Pkcs7SignerInfoRef

Source§

impl Send for Pkcs12

Source§

impl Send for Pkcs12Ref

Source§

impl Send for Provider

Source§

impl Send for ProviderRef

Source§

impl Send for Signer<'_>

Source§

impl Send for Verifier<'_>

Source§

impl Send for SrtpProtectionProfile

Source§

impl Send for SrtpProtectionProfileRef

Source§

impl Send for Ssl

Source§

impl Send for SslContext

Source§

impl Send for SslContextRef

Source§

impl Send for SslMethod

Source§

impl Send for SslRef

Source§

impl Send for SslSession

Source§

impl Send for SslSessionRef

Source§

impl Send for OpensslString

Source§

impl Send for OpensslStringRef

Source§

impl Send for openssl::symm::Cipher

Source§

impl Send for X509Store

Source§

impl Send for X509StoreBuilder

Source§

impl Send for X509StoreBuilderRef

Source§

impl Send for X509StoreRef

Source§

impl Send for AccessDescription

Source§

impl Send for AccessDescriptionRef

Source§

impl Send for DistPoint

Source§

impl Send for DistPointName

Source§

impl Send for DistPointNameRef

Source§

impl Send for DistPointRef

Source§

impl Send for GeneralName

Source§

impl Send for GeneralNameRef

Source§

impl Send for X509

Source§

impl Send for X509Algorithm

Source§

impl Send for X509AlgorithmRef

Source§

impl Send for X509Crl

Source§

impl Send for X509CrlRef

Source§

impl Send for X509Extension

Source§

impl Send for X509ExtensionRef

Source§

impl Send for X509Name

Source§

impl Send for X509NameEntry

Source§

impl Send for X509NameEntryRef

Source§

impl Send for X509NameRef

Source§

impl Send for X509Object

Source§

impl Send for X509ObjectRef

Source§

impl Send for X509Ref

Source§

impl Send for X509Req

Source§

impl Send for X509ReqRef

Source§

impl Send for X509Revoked

Source§

impl Send for X509RevokedRef

Source§

impl Send for X509StoreContext

Source§

impl Send for X509StoreContextRef

Source§

impl Send for X509VerifyParam

Source§

impl Send for X509VerifyParamRef

Source§

impl Send for BytesMut

Source§

impl Send for rustmax::core::ffi::c_str::Bytes<'_>

Source§

impl Send for rustmax::crossbeam::channel::Select<'_>

Source§

impl Send for Collector

Source§

impl Send for Parker

Source§

impl Send for Unparker

Source§

impl Send for rustmax::futures::task::AtomicWaker

Source§

impl Send for rustmax::hyper::body::Bytes

Source§

impl Send for rustmax::tokio::task::AbortHandle

1.6.0 · Source§

impl Send for rustmax::std::string::Drain<'_>

1.36.0 · Source§

impl Send for Waker

Source§

impl<'a> Send for Notified<'a>

1.44.0 · Source§

impl<'a> Send for IoSlice<'a>

1.44.0 · Source§

impl<'a> Send for IoSliceMut<'a>

Source§

impl<'a, R, T> Send for lock_api::mutex::MappedMutexGuard<'a, R, T>
where R: RawMutex + 'a, T: Send + 'a + ?Sized, <R as RawMutex>::GuardMarker: Send,

Source§

impl<'a, R, T> Send for lock_api::rwlock::MappedRwLockReadGuard<'a, R, T>
where R: RawRwLock + 'a, T: Sync + 'a + ?Sized, <R as RawRwLock>::GuardMarker: Send,

Source§

impl<'a, R, T> Send for lock_api::rwlock::MappedRwLockWriteGuard<'a, R, T>
where R: RawRwLock + 'a, T: Send + 'a + ?Sized, <R as RawRwLock>::GuardMarker: Send,

Source§

impl<'a, T> Send for smallvec::Drain<'a, T>
where T: Send + Array,

Source§

impl<'a, T> Send for ZeroVec<'a, T>
where T: AsULE, <T as AsULE>::ULE: Send + Sync,

Source§

impl<'a, T> Send for rustmax::reqwest::header::Drain<'a, T>
where T: Send,

Source§

impl<'a, T> Send for rustmax::reqwest::header::Iter<'a, T>
where T: Sync,

Source§

impl<'a, T> Send for rustmax::reqwest::header::IterMut<'a, T>
where T: Send,

Source§

impl<'a, T> Send for ValueDrain<'a, T>
where T: Send,

Source§

impl<'a, T> Send for ValueIterMut<'a, T>
where T: Send,

Source§

impl<'a, T> Send for rustmax::tokio::sync::MappedMutexGuard<'a, T>
where T: Send + 'a + ?Sized,

Source§

impl<'a, T, const CAP: usize> Send for arrayvec::arrayvec::Drain<'a, T, CAP>
where T: Send,

Source§

impl<A> Send for SmallVec<A>
where A: Array, <A as Array>::Item: Send,

Source§

impl<C> Send for CartableOptionPointer<C>

Source§

impl<Dyn> Send for DynMetadata<Dyn>
where Dyn: ?Sized,

Source§

impl<Fut> Send for rustmax::futures::prelude::stream::futures_unordered::IntoIter<Fut>
where Fut: Send + Unpin,

Source§

impl<Fut> Send for IterPinMut<'_, Fut>
where Fut: Send,

Source§

impl<Fut> Send for IterPinRef<'_, Fut>
where Fut: Send,

Source§

impl<Fut> Send for FuturesUnordered<Fut>
where Fut: Send,

Source§

impl<K, V> Send for hashbrown::map::IterMut<'_, K, V>
where K: Send, V: Send,

Source§

impl<K, V, S, A> Send for hashbrown::map::OccupiedEntry<'_, K, V, S, A>
where K: Send, V: Send, S: Send, A: Send + Allocator,

Source§

impl<R, G> Send for RawReentrantMutex<R, G>
where R: RawMutex + Send, G: GetThreadId + Send,

Source§

impl<R, G, T> Send for ReentrantMutex<R, G, T>
where R: RawMutex + Send, G: GetThreadId + Send, T: Send + ?Sized,

Source§

impl<R, T> Send for lock_api::mutex::Mutex<R, T>
where R: RawMutex + Send, T: Send + ?Sized,

Source§

impl<R, T> Send for lock_api::rwlock::RwLock<R, T>
where R: RawRwLock + Send, T: Send + ?Sized,

Source§

impl<S> Send for AllowStd<S>
where S: Send,

1.0.0 · Source§

impl<T> !Send for *const T
where T: ?Sized,

1.0.0 · Source§

impl<T> !Send for *mut T
where T: ?Sized,

1.25.0 · Source§

impl<T> !Send for NonNull<T>
where T: ?Sized,

NonNull pointers are not Send because the data they reference may be aliased.

Source§

impl<T> !Send for rustmax::std::sync::MappedMutexGuard<'_, T>
where T: ?Sized,

Source§

impl<T> !Send for rustmax::std::sync::MappedRwLockReadGuard<'_, T>
where T: ?Sized,

Source§

impl<T> !Send for rustmax::std::sync::MappedRwLockWriteGuard<'_, T>
where T: ?Sized,

1.0.0 · Source§

impl<T> !Send for rustmax::std::sync::MutexGuard<'_, T>
where T: ?Sized,

Source§

impl<T> !Send for ReentrantLockGuard<'_, T>
where T: ?Sized,

1.0.0 · Source§

impl<T> !Send for rustmax::std::sync::RwLockReadGuard<'_, T>
where T: ?Sized,

1.0.0 · Source§

impl<T> !Send for rustmax::std::sync::RwLockWriteGuard<'_, T>
where T: ?Sized,

1.0.0 · Source§

impl<T> Send for &T
where T: Sync + ?Sized,

Source§

impl<T> Send for libloading::os::unix::Symbol<T>
where T: Send,

Source§

impl<T> Send for libloading::safe::Symbol<'_, T>
where T: Send,

Source§

impl<T> Send for Dh<T>

Source§

impl<T> Send for DhRef<T>

Source§

impl<T> Send for Dsa<T>

Source§

impl<T> Send for DsaRef<T>

Source§

impl<T> Send for EcKey<T>

Source§

impl<T> Send for EcKeyRef<T>

Source§

impl<T> Send for PKey<T>

Source§

impl<T> Send for PKeyRef<T>

Source§

impl<T> Send for PkeyCtx<T>

Source§

impl<T> Send for PkeyCtxRef<T>

Source§

impl<T> Send for Rsa<T>

Source§

impl<T> Send for RsaRef<T>

Source§

impl<T> Send for openssl::stack::Stack<T>
where T: Stackable + Send,

Source§

impl<T> Send for StackRef<T>
where T: Stackable + Send,

Source§

impl<T> Send for X509Lookup<T>

Source§

impl<T> Send for X509LookupMethod<T>

Source§

impl<T> Send for X509LookupMethodRef<T>

Source§

impl<T> Send for X509LookupRef<T>

Source§

impl<T> Send for TryLock<T>
where T: Send,

Source§

impl<T> Send for AtomicCell<T>
where T: Send,

Source§

impl<T> Send for rustmax::crossbeam::channel::Receiver<T>
where T: Send,

Source§

impl<T> Send for rustmax::crossbeam::channel::Sender<T>
where T: Send,

Source§

impl<T> Send for Injector<T>
where T: Send,

Source§

impl<T> Send for Stealer<T>
where T: Send,

Source§

impl<T> Send for Worker<T>
where T: Send,

Source§

impl<T> Send for Atomic<T>
where T: Pointable + Send + Sync + ?Sized,

Source§

impl<T> Send for ArrayQueue<T>
where T: Send,

Source§

impl<T> Send for SegQueue<T>
where T: Send,

Source§

impl<T> Send for ShardedLock<T>
where T: Send + ?Sized,

Source§

impl<T> Send for rustmax::crossbeam::thread::ScopedJoinHandle<'_, T>

Source§

impl<T> Send for CachePadded<T>
where T: Send,

Source§

impl<T> Send for SharedPtr<T>
where T: Send + Sync + SharedPtrTarget,

Source§

impl<T> Send for UniquePtr<T>
where T: Send + UniquePtrTarget,

Source§

impl<T> Send for WeakPtr<T>
where T: Send + Sync + WeakPtrTarget,

Source§

impl<T> Send for rustmax::futures::lock::Mutex<T>
where T: Send + ?Sized,

Source§

impl<T> Send for rustmax::futures::lock::MutexGuard<'_, T>
where T: Send + ?Sized,

Source§

impl<T> Send for MutexLockFuture<'_, T>
where T: Send + ?Sized,

Source§

impl<T> Send for rustmax::futures::lock::OwnedMutexGuard<T>
where T: Send + ?Sized,

Source§

impl<T> Send for OwnedMutexLockFuture<T>
where T: Send + ?Sized,

Source§

impl<T> Send for FutureObj<'_, T>

Source§

impl<T> Send for rustmax::tokio::io::ReadHalf<T>
where T: Send,

Source§

impl<T> Send for rustmax::tokio::io::WriteHalf<T>
where T: Send,

Source§

impl<T> Send for rustmax::tokio::sync::broadcast::Receiver<T>
where T: Send,

Source§

impl<T> Send for rustmax::tokio::sync::broadcast::Sender<T>
where T: Send,

Source§

impl<T> Send for rustmax::tokio::sync::Mutex<T>
where T: Send + ?Sized,

Source§

impl<T> Send for rustmax::tokio::sync::OnceCell<T>
where T: Send,

Source§

impl<T> Send for OwnedRwLockWriteGuard<T>
where T: Send + Sync + ?Sized,

Source§

impl<T> Send for rustmax::tokio::sync::RwLock<T>
where T: Send + ?Sized,

Source§

impl<T> Send for RwLockMappedWriteGuard<'_, T>
where T: Send + Sync + ?Sized,

Source§

impl<T> Send for rustmax::tokio::sync::RwLockReadGuard<'_, T>
where T: Sync + ?Sized,

Source§

impl<T> Send for rustmax::tokio::sync::RwLockWriteGuard<'_, T>
where T: Send + Sync + ?Sized,

Source§

impl<T> Send for rustmax::tokio::task::JoinHandle<T>
where T: Send,

Source§

impl<T> Send for ThinBox<T>
where T: Send + ?Sized,

ThinBox<T> is Send if T is Send because the data is owned.

1.0.0 · Source§

impl<T> Send for Cell<T>
where T: Send + ?Sized,

1.0.0 · Source§

impl<T> Send for RefCell<T>
where T: Send + ?Sized,

1.0.0 · Source§

impl<T> Send for rustmax::std::collections::linked_list::Iter<'_, T>
where T: Sync,

1.0.0 · Source§

impl<T> Send for rustmax::std::collections::linked_list::IterMut<'_, T>
where T: Send,

1.28.0 · Source§

impl<T> Send for NonZero<T>

1.31.0 · Source§

impl<T> Send for rustmax::std::slice::ChunksExactMut<'_, T>
where T: Send,

1.0.0 · Source§

impl<T> Send for rustmax::std::slice::ChunksMut<'_, T>
where T: Send,

1.0.0 · Source§

impl<T> Send for rustmax::std::slice::Iter<'_, T>
where T: Sync,

1.0.0 · Source§

impl<T> Send for rustmax::std::slice::IterMut<'_, T>
where T: Send,

1.31.0 · Source§

impl<T> Send for rustmax::std::slice::RChunksExactMut<'_, T>
where T: Send,

1.31.0 · Source§

impl<T> Send for rustmax::std::slice::RChunksMut<'_, T>
where T: Send,

1.0.0 · Source§

impl<T> Send for AtomicPtr<T>

Source§

impl<T> Send for rustmax::std::sync::mpmc::Receiver<T>
where T: Send,

Source§

impl<T> Send for rustmax::std::sync::mpmc::Sender<T>
where T: Send,

1.0.0 · Source§

impl<T> Send for rustmax::std::sync::mpsc::Receiver<T>
where T: Send,

1.0.0 · Source§

impl<T> Send for rustmax::std::sync::mpsc::Sender<T>
where T: Send,

1.0.0 · Source§

impl<T> Send for SyncSender<T>
where T: Send,

1.0.0 · Source§

impl<T> Send for rustmax::std::sync::Mutex<T>
where T: Send + ?Sized,

1.70.0 · Source§

impl<T> Send for OnceLock<T>
where T: Send,

Source§

impl<T> Send for ReentrantLock<T>
where T: Send + ?Sized,

1.0.0 · Source§

impl<T> Send for rustmax::std::sync::RwLock<T>
where T: Send + ?Sized,

1.29.0 · Source§

impl<T> Send for rustmax::std::thread::JoinHandle<T>

1.0.0 · Source§

impl<T, A> !Send for Rc<T, A>
where A: Allocator, T: ?Sized,

1.4.0 · Source§

impl<T, A> !Send for rustmax::std::rc::Weak<T, A>
where A: Allocator, T: ?Sized,

Source§

impl<T, A> Send for hashbrown::table::OccupiedEntry<'_, T, A>
where T: Send, A: Send + Allocator,

Source§

impl<T, A> Send for rustmax::std::collections::linked_list::Cursor<'_, T, A>
where T: Sync, A: Allocator + Sync,

Source§

impl<T, A> Send for rustmax::std::collections::linked_list::CursorMut<'_, T, A>
where T: Send, A: Allocator + Send,

1.0.0 · Source§

impl<T, A> Send for LinkedList<T, A>
where T: Send, A: Allocator + Send,

1.6.0 · Source§

impl<T, A> Send for rustmax::std::collections::vec_deque::Drain<'_, T, A>
where T: Send, A: Allocator + Send,

1.0.0 · Source§

impl<T, A> Send for Arc<T, A>
where T: Sync + Send + ?Sized, A: Allocator + Send,

1.4.0 · Source§

impl<T, A> Send for rustmax::std::sync::Weak<T, A>
where T: Sync + Send + ?Sized, A: Allocator + Send,

1.6.0 · Source§

impl<T, A> Send for rustmax::std::vec::Drain<'_, T, A>
where T: Send, A: Send + Allocator,

1.0.0 · Source§

impl<T, A> Send for rustmax::std::vec::IntoIter<T, A>
where T: Send, A: Allocator + Send,

Source§

impl<T, N> Send for GenericArray<T, N>
where T: Send, N: ArrayLength<T>,

Source§

impl<T, U> Send for rustmax::futures::lock::MappedMutexGuard<'_, T, U>
where T: Send + ?Sized, U: Send + ?Sized,

Source§

impl<T, U> Send for OwnedMappedMutexGuard<T, U>
where T: Send + ?Sized, U: Send + ?Sized,

Source§

impl<T, U> Send for OwnedRwLockMappedWriteGuard<T, U>
where T: Send + Sync + ?Sized, U: Send + Sync + ?Sized,

Source§

impl<T, U> Send for OwnedRwLockReadGuard<T, U>
where T: Send + Sync + ?Sized, U: Sync + ?Sized,

Source§

impl<Tz> Send for rustmax::chrono::Date<Tz>
where Tz: TimeZone, <Tz as TimeZone>::Offset: Send,

Auto implementors§

§

impl !Send for rustmax::proc_macro2::TokenTree

§

impl !Send for AttrStyle

§

impl !Send for BinOp

§

impl !Send for CapturedParam

§

impl !Send for Data

§

impl !Send for rustmax::syn::Expr

§

impl !Send for Fields

§

impl !Send for FnArg

§

impl !Send for ForeignItem

§

impl !Send for GenericArgument

§

impl !Send for GenericParam

§

impl !Send for ImplItem

§

impl !Send for rustmax::syn::Item

§

impl !Send for Lit

§

impl !Send for MacroDelimiter

§

impl !Send for Member

§

impl !Send for Meta

§

impl !Send for Pat

§

impl !Send for PathArguments

§

impl !Send for PointerMutability

§

impl !Send for RangeLimits

§

impl !Send for ReturnType

§

impl !Send for StaticMutability

§

impl !Send for Stmt

§

impl !Send for TraitBoundModifier

§

impl !Send for TraitItem

§

impl !Send for rustmax::syn::Type

§

impl !Send for TypeParamBound

§

impl !Send for UnOp

§

impl !Send for UseTree

§

impl !Send for Visibility

§

impl !Send for WherePredicate

§

impl !Send for rustmax::backtrace::Symbol

§

impl !Send for Bindings

§

impl !Send for rustmax::bindgen::Builder

§

impl !Send for Guard

§

impl !Send for LocalHandle

§

impl !Send for rustmax::env_logger::fmt::Formatter

§

impl !Send for LocalPool

§

impl !Send for LocalSpawner

§

impl !Send for Dl_info

§

impl !Send for addrinfo

§

impl !Send for aiocb

§

impl !Send for dl_phdr_info

§

impl !Send for ff_periodic_effect

§

impl !Send for glob64_t

§

impl !Send for glob_t

§

impl !Send for group

§

impl !Send for hostent

§

impl !Send for if_nameindex

§

impl !Send for ifaddrs

§

impl !Send for ifconf

§

impl !Send for ifreq

§

impl !Send for iovec

§

impl !Send for iw_event

§

impl !Send for iw_point

§

impl !Send for iwreq

§

impl !Send for lconv

§

impl !Send for mcontext_t

§

impl !Send for mmsghdr

§

impl !Send for mntent

§

impl !Send for msghdr

§

impl !Send for option

§

impl !Send for passwd

§

impl !Send for posix_spawn_file_actions_t

§

impl !Send for protoent

§

impl !Send for regex_t

§

impl !Send for rtentry

§

impl !Send for servent

§

impl !Send for sigevent

§

impl !Send for sigval

§

impl !Send for sock_fprog

§

impl !Send for spwd

§

impl !Send for stack_t

§

impl !Send for tm

§

impl !Send for ucontext_t

§

impl !Send for user

§

impl !Send for rustmax::proc_macro2::extra::DelimSpan

§

impl !Send for rustmax::proc_macro2::Group

§

impl !Send for rustmax::proc_macro2::LexError

§

impl !Send for rustmax::proc_macro2::Literal

§

impl !Send for rustmax::proc_macro2::Punct

§

impl !Send for rustmax::proc_macro2::Span

§

impl !Send for rustmax::proc_macro2::TokenStream

§

impl !Send for rustmax::proc_macro2::token_stream::IntoIter

§

impl !Send for rustmax::proc_macro::Diagnostic

§

impl !Send for rustmax::proc_macro::Ident

§

impl !Send for rustmax::proc_macro::Literal

§

impl !Send for SourceFile

§

impl !Send for rustmax::proc_macro::token_stream::IntoIter

§

impl !Send for ThreadRng

§

impl !Send for FnContext

§

impl !Send for TokenBuffer

§

impl !Send for rustmax::syn::Abi

§

impl !Send for AngleBracketedGenericArguments

§

impl !Send for Arm

§

impl !Send for AssocConst

§

impl !Send for AssocType

§

impl !Send for Attribute

§

impl !Send for BareFnArg

§

impl !Send for BareVariadic

§

impl !Send for rustmax::syn::Block

§

impl !Send for BoundLifetimes

§

impl !Send for ConstParam

§

impl !Send for Constraint

§

impl !Send for DataEnum

§

impl !Send for DataStruct

§

impl !Send for DataUnion

§

impl !Send for DeriveInput

§

impl !Send for ExprArray

§

impl !Send for ExprAssign

§

impl !Send for ExprAsync

§

impl !Send for ExprAwait

§

impl !Send for ExprBinary

§

impl !Send for ExprBlock

§

impl !Send for ExprBreak

§

impl !Send for ExprCall

§

impl !Send for ExprCast

§

impl !Send for ExprClosure

§

impl !Send for ExprContinue

§

impl !Send for ExprField

§

impl !Send for ExprForLoop

§

impl !Send for ExprGroup

§

impl !Send for ExprIf

§

impl !Send for ExprIndex

§

impl !Send for ExprInfer

§

impl !Send for ExprLet

§

impl !Send for ExprLoop

§

impl !Send for ExprMatch

§

impl !Send for ExprMethodCall

§

impl !Send for ExprParen

§

impl !Send for ExprRawAddr

§

impl !Send for ExprReference

§

impl !Send for ExprRepeat

§

impl !Send for ExprReturn

§

impl !Send for ExprStruct

§

impl !Send for ExprTry

§

impl !Send for ExprTryBlock

§

impl !Send for ExprTuple

§

impl !Send for ExprUnary

§

impl !Send for ExprUnsafe

§

impl !Send for ExprWhile

§

impl !Send for ExprYield

§

impl !Send for Field

§

impl !Send for FieldPat

§

impl !Send for FieldValue

§

impl !Send for FieldsNamed

§

impl !Send for FieldsUnnamed

§

impl !Send for rustmax::syn::File

§

impl !Send for ForeignItemFn

§

impl !Send for ForeignItemMacro

§

impl !Send for ForeignItemStatic

§

impl !Send for ForeignItemType

§

impl !Send for Generics

§

impl !Send for rustmax::syn::Ident

§

impl !Send for ImplItemConst

§

impl !Send for ImplItemFn

§

impl !Send for ImplItemMacro

§

impl !Send for ImplItemType

§

impl !Send for rustmax::syn::Index

§

impl !Send for ItemConst

§

impl !Send for ItemEnum

§

impl !Send for ItemExternCrate

§

impl !Send for ItemFn

§

impl !Send for ItemForeignMod

§

impl !Send for ItemImpl

§

impl !Send for ItemMacro

§

impl !Send for ItemMod

§

impl !Send for ItemStatic

§

impl !Send for ItemStruct

§

impl !Send for ItemTrait

§

impl !Send for ItemTraitAlias

§

impl !Send for ItemType

§

impl !Send for ItemUnion

§

impl !Send for ItemUse

§

impl !Send for Label

§

impl !Send for Lifetime

§

impl !Send for LifetimeParam

§

impl !Send for LitBool

§

impl !Send for LitByte

§

impl !Send for LitByteStr

§

impl !Send for LitCStr

§

impl !Send for LitChar

§

impl !Send for LitFloat

§

impl !Send for LitInt

§

impl !Send for LitStr

§

impl !Send for rustmax::syn::Local

§

impl !Send for LocalInit

§

impl !Send for rustmax::syn::Macro

§

impl !Send for MetaList

§

impl !Send for MetaNameValue

§

impl !Send for ParenthesizedGenericArguments

§

impl !Send for ExprConst

§

impl !Send for PatIdent

§

impl !Send for ExprLit

§

impl !Send for ExprMacro

§

impl !Send for PatOr

§

impl !Send for PatParen

§

impl !Send for ExprPath

§

impl !Send for ExprRange

§

impl !Send for PatReference

§

impl !Send for PatRest

§

impl !Send for PatSlice

§

impl !Send for PatStruct

§

impl !Send for PatTuple

§

impl !Send for PatTupleStruct

§

impl !Send for PatType

§

impl !Send for PatWild

§

impl !Send for rustmax::syn::Path

§

impl !Send for PathSegment

§

impl !Send for PreciseCapture

§

impl !Send for PredicateLifetime

§

impl !Send for PredicateType

§

impl !Send for QSelf

§

impl !Send for rustmax::syn::Receiver

§

impl !Send for Signature

§

impl !Send for StmtMacro

§

impl !Send for TraitBound

§

impl !Send for TraitItemConst

§

impl !Send for TraitItemFn

§

impl !Send for TraitItemMacro

§

impl !Send for TraitItemType

§

impl !Send for TypeArray

§

impl !Send for TypeBareFn

§

impl !Send for TypeGroup

§

impl !Send for TypeImplTrait

§

impl !Send for TypeInfer

§

impl !Send for TypeMacro

§

impl !Send for TypeNever

§

impl !Send for TypeParam

§

impl !Send for TypeParen

§

impl !Send for TypePath

§

impl !Send for TypePtr

§

impl !Send for TypeReference

§

impl !Send for TypeSlice

§

impl !Send for TypeTraitObject

§

impl !Send for TypeTuple

§

impl !Send for UseGlob

§

impl !Send for UseGroup

§

impl !Send for UseName

§

impl !Send for UsePath

§

impl !Send for UseRename

§

impl !Send for Variadic

§

impl !Send for Variant

§

impl !Send for VisRestricted

§

impl !Send for WhereClause

§

impl !Send for Abstract

§

impl !Send for rustmax::syn::token::And

§

impl !Send for AndAnd

§

impl !Send for AndEq

§

impl !Send for As

§

impl !Send for Async

§

impl !Send for rustmax::syn::token::At

§

impl !Send for Auto

§

impl !Send for Await

§

impl !Send for Become

§

impl !Send for rustmax::syn::token::Box

§

impl !Send for Brace

§

impl !Send for Bracket

§

impl !Send for Break

§

impl !Send for Caret

§

impl !Send for CaretEq

§

impl !Send for Colon

§

impl !Send for Comma

§

impl !Send for Const

§

impl !Send for Continue

§

impl !Send for Crate

§

impl !Send for Default

§

impl !Send for Do

§

impl !Send for Dollar

§

impl !Send for Dot

§

impl !Send for DotDot

§

impl !Send for DotDotDot

§

impl !Send for DotDotEq

§

impl !Send for Dyn

§

impl !Send for Else

§

impl !Send for Enum

§

impl !Send for Eq

§

impl !Send for EqEq

§

impl !Send for Extern

§

impl !Send for FatArrow

§

impl !Send for Final

§

impl !Send for Fn

§

impl !Send for For

§

impl !Send for Ge

§

impl !Send for rustmax::syn::token::Group

§

impl !Send for Gt

§

impl !Send for rustmax::syn::token::If

§

impl !Send for Impl

§

impl !Send for rustmax::syn::token::In

§

impl !Send for LArrow

§

impl !Send for Le

§

impl !Send for Let

§

impl !Send for Loop

§

impl !Send for Lt

§

impl !Send for rustmax::syn::token::Macro

§

impl !Send for rustmax::syn::token::Match

§

impl !Send for Minus

§

impl !Send for MinusEq

§

impl !Send for Mod

§

impl !Send for Move

§

impl !Send for Mut

§

impl !Send for Ne

§

impl !Send for rustmax::syn::token::Not

§

impl !Send for rustmax::syn::token::Or

§

impl !Send for OrEq

§

impl !Send for OrOr

§

impl !Send for Override

§

impl !Send for Paren

§

impl !Send for PathSep

§

impl !Send for Percent

§

impl !Send for PercentEq

§

impl !Send for Plus

§

impl !Send for PlusEq

§

impl !Send for Pound

§

impl !Send for Priv

§

impl !Send for Pub

§

impl !Send for Question

§

impl !Send for RArrow

§

impl !Send for Raw

§

impl !Send for rustmax::syn::token::Ref

§

impl !Send for Return

§

impl !Send for SelfType

§

impl !Send for SelfValue

§

impl !Send for Semi

§

impl !Send for Shl

§

impl !Send for ShlEq

§

impl !Send for Shr

§

impl !Send for ShrEq

§

impl !Send for Slash

§

impl !Send for SlashEq

§

impl !Send for Star

§

impl !Send for StarEq

§

impl !Send for Static

§

impl !Send for Struct

§

impl !Send for Super

§

impl !Send for Tilde

§

impl !Send for Trait

§

impl !Send for Try

§

impl !Send for rustmax::syn::token::Type

§

impl !Send for Typeof

§

impl !Send for Underscore

§

impl !Send for rustmax::syn::token::Union

§

impl !Send for Unsafe

§

impl !Send for Unsized

§

impl !Send for Use

§

impl !Send for Virtual

§

impl !Send for Where

§

impl !Send for While

§

impl !Send for rustmax::syn::token::Yield

§

impl !Send for LocalEnterGuard

§

impl !Send for LocalSet

§

impl !Send for Vars

§

impl !Send for VarsOs

§

impl !Send for RawWaker

§

impl !Send for __c_anonymous_ifc_ifcu

§

impl !Send for __c_anonymous_ifr_ifru

§

impl !Send for iwreq_data

§

impl Send for rustmax::axum::extract::path::ErrorKind

§

impl Send for BytesRejection

§

impl Send for ExtensionRejection

§

impl Send for FailedToBufferBody

§

impl Send for FormRejection

§

impl Send for JsonRejection

§

impl Send for MatchedPathRejection

§

impl Send for PathRejection

§

impl Send for QueryRejection

§

impl Send for RawFormRejection

§

impl Send for RawPathParamsRejection

§

impl Send for StringRejection

§

impl Send for PrintFmt

§

impl Send for ParseAlphabetError

§

impl Send for DecodePaddingMode

§

impl Send for DecodeError

§

impl Send for DecodeSliceError

§

impl Send for EncodeSliceError

§

impl Send for DeriveTrait

§

impl Send for DiscoveredItem

§

impl Send for EnumVariantCustomBehavior

§

impl Send for EnumVariantValue

§

impl Send for CanDerive

§

impl Send for IntKind

§

impl Send for ItemKind

§

impl Send for MacroParsingBehavior

§

impl Send for TypeKind

§

impl Send for rustmax::bindgen::Abi

§

impl Send for AliasVariation

§

impl Send for BindgenError

§

impl Send for EnumVariation

§

impl Send for FieldVisibilityKind

§

impl Send for rustmax::bindgen::Formatter

§

impl Send for MacroTypeVariation

§

impl Send for NonCopyUnionStyle

§

impl Send for RustEdition

§

impl Send for BigEndian

§

impl Send for LittleEndian

§

impl Send for VsVers

§

impl Send for Month

§

impl Send for RoundingError

§

impl Send for SecondsFormat

§

impl Send for rustmax::chrono::Weekday

§

impl Send for Colons

§

impl Send for Fixed

§

impl Send for Numeric

§

impl Send for OffsetPrecision

§

impl Send for Pad

§

impl Send for ParseErrorKind

§

impl Send for ArgPredicate

§

impl Send for ArgAction

§

impl Send for rustmax::clap::ColorChoice

§

impl Send for ValueHint

§

impl Send for ContextKind

§

impl Send for ContextValue

§

impl Send for rustmax::clap::error::ErrorKind

§

impl Send for MatchesError

§

impl Send for ValueSource

§

impl Send for rustmax::crossbeam::channel::RecvTimeoutError

§

impl Send for rustmax::crossbeam::channel::TryRecvError

§

impl Send for rustmax::ctrlc::Error

§

impl Send for SignalType

§

impl Send for Opaque

§

impl Send for Trivial

§

impl Send for BinaryError

§

impl Send for Target

§

impl Send for TimestampPrecision

§

impl Send for WriteStyle

§

impl Send for AnsiColor

§

impl Send for rustmax::env_logger::fmt::style::Color

§

impl Send for PollNext

§

impl Send for FromHexError

§

impl Send for rustmax::itertools::Position

§

impl Send for Era

§

impl Send for rustmax::jiff::civil::Weekday

§

impl Send for RoundMode

§

impl Send for Unit

§

impl Send for Designator

§

impl Send for rustmax::jiff::fmt::friendly::Direction

§

impl Send for FractionalUnit

§

impl Send for rustmax::jiff::fmt::friendly::Spacing

§

impl Send for Meridiem

§

impl Send for PiecesOffset

§

impl Send for AmbiguousOffset

§

impl Send for Disambiguation

§

impl Send for Dst

§

impl Send for OffsetConflict

§

impl Send for rustmax::json5::Error

§

impl Send for DIR

§

impl Send for FILE

§

impl Send for fpos64_t

§

impl Send for fpos_t

§

impl Send for timezone

§

impl Send for tpacket_versions

§

impl Send for rustmax::log::Level

§

impl Send for LevelFilter

§

impl Send for CompareResult

§

impl Send for Needed

§

impl Send for rustmax::nom::error::ErrorKind

§

impl Send for Endianness

§

impl Send for rustmax::num_bigint::Sign

§

impl Send for rustmax::proc_macro2::Delimiter

§

impl Send for rustmax::proc_macro2::Spacing

§

impl Send for rustmax::proc_macro::Delimiter

§

impl Send for rustmax::proc_macro::Level

§

impl Send for rustmax::proc_macro::Spacing

§

impl Send for TestCaseError

§

impl Send for rustmax::proptest::string::Error

§

impl Send for FileFailurePersistence

§

impl Send for RngAlgorithm

§

impl Send for BernoulliError

§

impl Send for rustmax::rand::distr::uniform::Error

§

impl Send for rustmax::rand::seq::WeightError

§

impl Send for IndexVec

§

impl Send for IndexVecIntoIter

§

impl Send for rustmax::rayon::Yield

§

impl Send for rustmax::regex::Error

§

impl Send for Quote

§

impl Send for BellStyle

§

impl Send for Anchor

§

impl Send for rustmax::rustyline::At

§

impl Send for Behavior

§

impl Send for CharSearch

§

impl Send for rustmax::rustyline::Cmd

§

impl Send for ColorMode

§

impl Send for CompletionType

§

impl Send for EditMode

§

impl Send for rustmax::rustyline::Event

§

impl Send for EventHandler

§

impl Send for HistoryDuplicates

§

impl Send for InputMode

§

impl Send for KeyCode

§

impl Send for Movement

§

impl Send for Word

§

impl Send for ReadlineError

§

impl Send for CmdKind

§

impl Send for SearchDirection

§

impl Send for rustmax::rustyline::line_buffer::Direction

§

impl Send for WordAction

§

impl Send for ValidationResult

§

impl Send for Op

§

impl Send for Category

§

impl Send for CharEscape

§

impl Send for TruncSide

§

impl Send for InterfaceIndexOrAddress

§

impl Send for FieldMutability

§

impl Send for ImplRestriction

§

impl Send for SpooledData

§

impl Send for ExprVal

§

impl Send for LogicOperator

§

impl Send for MathOperator

§

impl Send for Node

§

impl Send for rustmax::tera::ErrorKind

§

impl Send for rustmax::tera::Value

§

impl Send for rustmax::termcolor::Color

§

impl Send for rustmax::termcolor::ColorChoice

§

impl Send for RuntimeFlavor

§

impl Send for rustmax::tokio::sync::broadcast::error::RecvError

§

impl Send for rustmax::tokio::sync::broadcast::error::TryRecvError

§

impl Send for TryAcquireError

§

impl Send for rustmax::tokio::sync::mpsc::error::TryRecvError

§

impl Send for rustmax::tokio::sync::oneshot::error::TryRecvError

§

impl Send for MissedTickBehavior

§

impl Send for rustmax::toml::Value

§

impl Send for rustmax::toml::value::Offset

§

impl Send for GraphemeIncomplete

§

impl Send for Origin

§

impl Send for rustmax::url::ParseError

§

impl Send for rustmax::url::Position

§

impl Send for SyntaxViolation

§

impl Send for AsciiChar

§

impl Send for BacktraceStatus

§

impl Send for rustmax::std::cmp::Ordering

§

impl Send for TryReserveErrorKind

§

impl Send for Infallible

§

impl Send for VarError

§

impl Send for c_void

§

impl Send for rustmax::std::fmt::Alignment

§

impl Send for BasicBlock

§

impl Send for UnwindTerminateReason

§

impl Send for rustmax::std::io::ErrorKind

§

impl Send for SeekFrom

§

impl Send for IpAddr

§

impl Send for Ipv6MulticastScope

§

impl Send for Shutdown

§

impl Send for rustmax::std::net::SocketAddr

§

impl Send for FpCategory

§

impl Send for IntErrorKind

§

impl Send for AncillaryError

§

impl Send for BacktraceStyle

§

impl Send for SearchStep

§

impl Send for rustmax::std::sync::atomic::Ordering

§

impl Send for rustmax::std::sync::mpsc::RecvTimeoutError

§

impl Send for rustmax::std::sync::mpsc::TryRecvError

§

impl Send for AHasher

§

impl Send for rustmax::ahash::RandomState

§

impl Send for rustmax::anyhow::Error

§

impl Send for rustmax::axum::body::Body

§

impl Send for BodyDataStream

§

impl Send for HandleErrorFuture

§

impl Send for FailedToDeserializeForm

§

impl Send for FailedToDeserializeFormBody

§

impl Send for FailedToDeserializePathParams

§

impl Send for FailedToDeserializeQueryString

§

impl Send for InvalidFormContentType

§

impl Send for InvalidUtf8

§

impl Send for InvalidUtf8InPathParam

§

impl Send for JsonDataError

§

impl Send for JsonSyntaxError

§

impl Send for LengthLimitError

§

impl Send for MatchedPathMissing

§

impl Send for MissingExtension

§

impl Send for MissingJsonContentType

§

impl Send for MissingPathParams

§

impl Send for NestedPathRejection

§

impl Send for UnknownBodyError

§

impl Send for DefaultBodyLimit

§

impl Send for MatchedPath

§

impl Send for NestedPath

§

impl Send for OriginalUri

§

impl Send for RawForm

§

impl Send for RawPathParams

§

impl Send for RawQuery

§

impl Send for rustmax::axum::middleware::future::FromFnResponseFuture

§

impl Send for rustmax::axum::middleware::future::MapRequestResponseFuture

§

impl Send for rustmax::axum::middleware::future::MapResponseResponseFuture

§

impl Send for rustmax::axum::middleware::Next

§

impl Send for rustmax::axum::response::sse::Event

§

impl Send for KeepAlive

§

impl Send for ErrorResponse

§

impl Send for NoContent

§

impl Send for Redirect

§

impl Send for ResponseParts

§

impl Send for InfallibleRouteFuture

§

impl Send for MethodFilter

§

impl Send for rustmax::axum::Error

§

impl Send for rustmax::backtrace::Backtrace

§

impl Send for rustmax::backtrace::BacktraceFrame

§

impl Send for BacktraceSymbol

§

impl Send for rustmax::backtrace::Frame

§

impl Send for Alphabet

§

impl Send for DecodeMetadata

§

impl Send for GeneralPurpose

§

impl Send for GeneralPurposeConfig

§

impl Send for DiscoveredItemId

§

impl Send for CargoCallbacks

§

impl Send for ClangVersion

§

impl Send for CodegenConfig

§

impl Send for RustTarget

§

impl Send for rustmax::bitflags::parser::ParseError

§

impl Send for Hash

§

impl Send for rustmax::blake3::Hasher

§

impl Send for HexError

§

impl Send for OutputReader

§

impl Send for UninitSlice

§

impl Send for Build

§

impl Send for rustmax::cc::Error

§

impl Send for Tool

§

impl Send for InternalFixed

§

impl Send for InternalNumeric

§

impl Send for OffsetFormat

§

impl Send for Parsed

§

impl Send for NaiveDateDaysIterator

§

impl Send for NaiveDateWeeksIterator

§

impl Send for Days

§

impl Send for FixedOffset

§

impl Send for IsoWeek

§

impl Send for rustmax::chrono::Local

§

impl Send for Months

§

impl Send for NaiveDate

§

impl Send for NaiveDateTime

§

impl Send for NaiveTime

§

impl Send for NaiveWeek

§

impl Send for OutOfRange

§

impl Send for OutOfRangeError

§

impl Send for rustmax::chrono::ParseError

§

impl Send for ParseMonthError

§

impl Send for ParseWeekdayError

§

impl Send for TimeDelta

§

impl Send for Utc

§

impl Send for BoolValueParser

§

impl Send for BoolishValueParser

§

impl Send for FalseyValueParser

§

impl Send for NonEmptyStringValueParser

§

impl Send for rustmax::clap::builder::OsStr

§

impl Send for OsStringValueParser

§

impl Send for PathBufValueParser

§

impl Send for PossibleValue

§

impl Send for PossibleValuesParser

§

impl Send for Str

§

impl Send for StringValueParser

§

impl Send for StyledStr

§

impl Send for Styles

§

impl Send for UnknownArgumentValueParser

§

impl Send for ValueParser

§

impl Send for ValueRange

§

impl Send for RichFormatter

§

impl Send for KindFormatter

§

impl Send for Arg

§

impl Send for ArgGroup

§

impl Send for ArgMatches

§

impl Send for rustmax::clap::Command

§

impl Send for rustmax::clap::Id

§

impl Send for ReadyTimeoutError

§

impl Send for rustmax::crossbeam::channel::RecvError

§

impl Send for SelectTimeoutError

§

impl Send for TryReadyError

§

impl Send for TrySelectError

§

impl Send for WaitGroup

§

impl Send for Backoff

§

impl Send for CxxString

§

impl Send for Exception

§

impl Send for rustmax::derive_more::FromStrError

§

impl Send for rustmax::derive_more::UnitError

§

impl Send for WrongVariantError

§

impl Send for rustmax::env_logger::fmt::Timestamp

§

impl Send for Ansi256Color

§

impl Send for EffectIter

§

impl Send for Effects

§

impl Send for Reset

§

impl Send for RgbColor

§

impl Send for Style

§

impl Send for rustmax::env_logger::Builder

§

impl Send for Logger

§

impl Send for rustmax::futures::channel::mpsc::SendError

§

impl Send for rustmax::futures::channel::mpsc::TryRecvError

§

impl Send for Canceled

§

impl Send for Enter

§

impl Send for EnterError

§

impl Send for rustmax::futures::io::Empty

§

impl Send for rustmax::futures::io::Repeat

§

impl Send for rustmax::futures::io::Sink

§

impl Send for rustmax::futures::prelude::stream::AbortHandle

§

impl Send for AbortRegistration

§

impl Send for Aborted

§

impl Send for SpawnError

§

impl Send for rustmax::hyper::body::Incoming

§

impl Send for SizeHint

§

impl Send for rustmax::hyper::client::conn::http1::Builder

§

impl Send for rustmax::hyper::ext::Protocol

§

impl Send for ReasonPhrase

§

impl Send for InvalidMethod

§

impl Send for rustmax::hyper::http::request::Builder

§

impl Send for rustmax::hyper::http::request::Parts

§

impl Send for rustmax::hyper::http::response::Builder

§

impl Send for rustmax::hyper::http::response::Parts

§

impl Send for InvalidStatusCode

§

impl Send for rustmax::hyper::http::Error

§

impl Send for Extensions

§

impl Send for Authority

§

impl Send for rustmax::hyper::http::uri::Builder

§

impl Send for InvalidUri

§

impl Send for InvalidUriParts

§

impl Send for rustmax::hyper::http::uri::Parts

§

impl Send for PathAndQuery

§

impl Send for Scheme

§

impl Send for rustmax::hyper::server::conn::http1::Builder

§

impl Send for rustmax::hyper::Error

§

impl Send for Uri

§

impl Send for OnUpgrade

§

impl Send for rustmax::hyper::upgrade::Upgraded

§

impl Send for rustmax::jiff::civil::Date

§

impl Send for DateArithmetic

§

impl Send for DateDifference

§

impl Send for DateSeries

§

impl Send for rustmax::jiff::civil::DateTime

§

impl Send for DateTimeArithmetic

§

impl Send for DateTimeDifference

§

impl Send for DateTimeRound

§

impl Send for DateTimeSeries

§

impl Send for DateTimeWith

§

impl Send for DateWith

§

impl Send for ISOWeekDate

§

impl Send for rustmax::jiff::civil::Time

§

impl Send for TimeArithmetic

§

impl Send for TimeDifference

§

impl Send for TimeRound

§

impl Send for TimeSeries

§

impl Send for TimeWith

§

impl Send for WeekdaysForward

§

impl Send for WeekdaysReverse

§

impl Send for rustmax::jiff::fmt::friendly::SpanParser

§

impl Send for rustmax::jiff::fmt::friendly::SpanPrinter

§

impl Send for rustmax::jiff::fmt::rfc2822::DateTimeParser

§

impl Send for rustmax::jiff::fmt::rfc2822::DateTimePrinter

§

impl Send for BrokenDownTime

§

impl Send for rustmax::jiff::fmt::temporal::DateTimeParser

§

impl Send for rustmax::jiff::fmt::temporal::DateTimePrinter

§

impl Send for PiecesNumericOffset

§

impl Send for rustmax::jiff::fmt::temporal::SpanParser

§

impl Send for rustmax::jiff::fmt::temporal::SpanPrinter

§

impl Send for rustmax::jiff::Error

§

impl Send for SignedDuration

§

impl Send for SignedDurationRound

§

impl Send for rustmax::jiff::Span

§

impl Send for SpanFieldwise

§

impl Send for rustmax::jiff::Timestamp

§

impl Send for TimestampArithmetic

§

impl Send for TimestampDifference

§

impl Send for TimestampDisplayWithOffset

§

impl Send for TimestampRound

§

impl Send for TimestampSeries

§

impl Send for Zoned

§

impl Send for ZonedArithmetic

§

impl Send for ZonedRound

§

impl Send for ZonedWith

§

impl Send for AmbiguousTimestamp

§

impl Send for AmbiguousZoned

§

impl Send for rustmax::jiff::tz::Offset

§

impl Send for OffsetArithmetic

§

impl Send for OffsetRound

§

impl Send for TimeZone

§

impl Send for TimeZoneDatabase

§

impl Send for rustmax::json5::Location

§

impl Send for Elf32_Chdr

§

impl Send for Elf32_Ehdr

§

impl Send for Elf32_Phdr

§

impl Send for Elf32_Shdr

§

impl Send for Elf32_Sym

§

impl Send for Elf64_Chdr

§

impl Send for Elf64_Ehdr

§

impl Send for Elf64_Phdr

§

impl Send for Elf64_Shdr

§

impl Send for Elf64_Sym

§

impl Send for __c_anonymous__kernel_fsid_t

§

impl Send for __c_anonymous_elf32_rel

§

impl Send for __c_anonymous_elf32_rela

§

impl Send for __c_anonymous_elf64_rel

§

impl Send for __c_anonymous_elf64_rela

§

impl Send for __c_anonymous_ifru_map

§

impl Send for __c_anonymous_ptrace_syscall_info_entry

§

impl Send for __c_anonymous_ptrace_syscall_info_exit

§

impl Send for __c_anonymous_ptrace_syscall_info_seccomp

§

impl Send for __c_anonymous_sockaddr_can_j1939

§

impl Send for __c_anonymous_sockaddr_can_tp

§

impl Send for __exit_status

§

impl Send for __timeval

§

impl Send for _libc_fpstate

§

impl Send for _libc_fpxreg

§

impl Send for _libc_xmmreg

§

impl Send for af_alg_iv

§

impl Send for arpd_request

§

impl Send for arphdr

§

impl Send for arpreq

§

impl Send for arpreq_old

§

impl Send for can_filter

§

impl Send for can_frame

§

impl Send for canfd_frame

§

impl Send for canxl_frame

§

impl Send for clone_args

§

impl Send for cmsghdr

§

impl Send for cpu_set_t

§

impl Send for dirent64

§

impl Send for dirent

§

impl Send for dqblk

§

impl Send for epoll_event

§

impl Send for epoll_params

§

impl Send for fanotify_event_info_error

§

impl Send for fanotify_event_info_fid

§

impl Send for fanotify_event_info_header

§

impl Send for fanotify_event_info_pidfd

§

impl Send for fanotify_event_metadata

§

impl Send for fanotify_response

§

impl Send for fanout_args

§

impl Send for fd_set

§

impl Send for ff_condition_effect

§

impl Send for ff_constant_effect

§

impl Send for ff_effect

§

impl Send for ff_envelope

§

impl Send for ff_ramp_effect

§

impl Send for ff_replay

§

impl Send for ff_rumble_effect

§

impl Send for ff_trigger

§

impl Send for file_clone_range

§

impl Send for flock64

§

impl Send for flock

§

impl Send for fsid_t

§

impl Send for genlmsghdr

§

impl Send for hwtstamp_config

§

impl Send for in6_addr

§

impl Send for in6_ifreq

§

impl Send for in6_pktinfo

§

impl Send for in6_rtmsg

§

impl Send for in_addr

§

impl Send for in_pktinfo

§

impl Send for inotify_event

§

impl Send for input_absinfo

§

impl Send for input_event

§

impl Send for input_id

§

impl Send for input_keymap_entry

§

impl Send for input_mask

§

impl Send for iocb

§

impl Send for ip_mreq

§

impl Send for ip_mreq_source

§

impl Send for ip_mreqn

§

impl Send for ipc_perm

§

impl Send for ipv6_mreq

§

impl Send for itimerspec

§

impl Send for itimerval

§

impl Send for iw_discarded

§

impl Send for iw_encode_ext

§

impl Send for iw_freq

§

impl Send for iw_michaelmicfailure

§

impl Send for iw_missed

§

impl Send for iw_mlme

§

impl Send for iw_param

§

impl Send for iw_pmkid_cand

§

impl Send for iw_pmksa

§

impl Send for iw_priv_args

§

impl Send for iw_quality

§

impl Send for iw_range

§

impl Send for iw_scan_req

§

impl Send for iw_statistics

§

impl Send for iw_thrspy

§

impl Send for j1939_filter

§

impl Send for linger

§

impl Send for mallinfo2

§

impl Send for mallinfo

§

impl Send for max_align_t

§

impl Send for mount_attr

§

impl Send for mq_attr

§

impl Send for msginfo

§

impl Send for msqid_ds

§

impl Send for nl_mmap_hdr

§

impl Send for nl_mmap_req

§

impl Send for nl_pktinfo

§

impl Send for nlattr

§

impl Send for nlmsgerr

§

impl Send for nlmsghdr

§

impl Send for ntptimeval

§

impl Send for open_how

§

impl Send for packet_mreq

§

impl Send for pollfd

§

impl Send for posix_spawnattr_t

§

impl Send for pthread_attr_t

§

impl Send for pthread_barrier_t

§

impl Send for pthread_barrierattr_t

§

impl Send for pthread_cond_t

§

impl Send for pthread_condattr_t

§

impl Send for pthread_mutex_t

§

impl Send for pthread_mutexattr_t

§

impl Send for pthread_rwlock_t

§

impl Send for pthread_rwlockattr_t

§

impl Send for ptp_clock_caps

§

impl Send for ptp_clock_time

§

impl Send for ptp_extts_event

§

impl Send for ptp_extts_request

§

impl Send for ptp_perout_request

§

impl Send for ptp_pin_desc

§

impl Send for ptp_sys_offset

§

impl Send for ptp_sys_offset_extended

§

impl Send for ptp_sys_offset_precise

§

impl Send for ptrace_peeksiginfo_args

§

impl Send for ptrace_rseq_configuration

§

impl Send for ptrace_syscall_info

§

impl Send for regmatch_t

§

impl Send for rlimit64

§

impl Send for rlimit

§

impl Send for rusage

§

impl Send for sched_attr

§

impl Send for sched_param

§

impl Send for sctp_authinfo

§

impl Send for sctp_initmsg

§

impl Send for sctp_nxtinfo

§

impl Send for sctp_prinfo

§

impl Send for sctp_rcvinfo

§

impl Send for sctp_sndinfo

§

impl Send for sctp_sndrcvinfo

§

impl Send for seccomp_data

§

impl Send for seccomp_notif

§

impl Send for seccomp_notif_addfd

§

impl Send for seccomp_notif_resp

§

impl Send for seccomp_notif_sizes

§

impl Send for sem_t

§

impl Send for sembuf

§

impl Send for semid_ds

§

impl Send for seminfo

§

impl Send for shmid_ds

§

impl Send for sigaction

§

impl Send for siginfo_t

§

impl Send for signalfd_siginfo

§

impl Send for sigset_t

§

impl Send for sock_extended_err

§

impl Send for sock_filter

§

impl Send for sock_txtime

§

impl Send for sockaddr

§

impl Send for sockaddr_alg

§

impl Send for sockaddr_can

§

impl Send for sockaddr_in6

§

impl Send for sockaddr_in

§

impl Send for sockaddr_ll

§

impl Send for sockaddr_nl

§

impl Send for sockaddr_pkt

§

impl Send for sockaddr_storage

§

impl Send for sockaddr_un

§

impl Send for sockaddr_vm

§

impl Send for sockaddr_xdp

§

impl Send for stat64

§

impl Send for rustmax::libc::stat

§

impl Send for statfs64

§

impl Send for statfs

§

impl Send for statvfs64

§

impl Send for statvfs

§

impl Send for statx

§

impl Send for statx_timestamp

§

impl Send for sysinfo

§

impl Send for tcp_info

§

impl Send for termios2

§

impl Send for termios

§

impl Send for timespec

§

impl Send for timeval

§

impl Send for timex

§

impl Send for tls12_crypto_info_aes_gcm_128

§

impl Send for tls12_crypto_info_aes_gcm_256

§

impl Send for tls12_crypto_info_chacha20_poly1305

§

impl Send for tls_crypto_info

§

impl Send for tms

§

impl Send for tpacket2_hdr

§

impl Send for tpacket3_hdr

§

impl Send for tpacket_auxdata

§

impl Send for tpacket_bd_ts

§

impl Send for tpacket_block_desc

§

impl Send for tpacket_hdr

§

impl Send for tpacket_hdr_v1

§

impl Send for tpacket_hdr_variant1

§

impl Send for tpacket_req3

§

impl Send for tpacket_req

§

impl Send for tpacket_rollover_stats

§

impl Send for tpacket_stats

§

impl Send for tpacket_stats_v3

§

impl Send for ucred

§

impl Send for uinput_abs_setup

§

impl Send for uinput_ff_erase

§

impl Send for uinput_ff_upload

§

impl Send for uinput_setup

§

impl Send for uinput_user_dev

§

impl Send for user_fpregs_struct

§

impl Send for user_regs_struct

§

impl Send for utimbuf

§

impl Send for utmpx

§

impl Send for utsname

§

impl Send for winsize

§

impl Send for xdp_desc

§

impl Send for xdp_mmap_offsets

§

impl Send for xdp_mmap_offsets_v1

§

impl Send for xdp_options

§

impl Send for xdp_ring_offset

§

impl Send for xdp_ring_offset_v1

§

impl Send for xdp_statistics

§

impl Send for xdp_statistics_v1

§

impl Send for xdp_umem_reg

§

impl Send for xdp_umem_reg_v1

§

impl Send for xsk_tx_metadata

§

impl Send for xsk_tx_metadata_completion

§

impl Send for xsk_tx_metadata_request

§

impl Send for ParseLevelError

§

impl Send for SetLoggerError

§

impl Send for rustmax::mime::FromStrError

§

impl Send for Mime

§

impl Send for Check

§

impl Send for Complete

§

impl Send for Emit

§

impl Send for SaturatingIterator

§

impl Send for Streaming

§

impl Send for BigInt

§

impl Send for BigUint

§

impl Send for ParseBigIntError

§

impl Send for LineColumn

§

impl Send for VarBitSet

§

impl Send for rustmax::proptest::bool::Any

§

impl Send for BoolValueTree

§

impl Send for Weighted

§

impl Send for CharValueTree

§

impl Send for rustmax::proptest::num::f32::Any

§

impl Send for rustmax::proptest::num::f32::BinarySearch

§

impl Send for rustmax::proptest::num::f64::Any

§

impl Send for rustmax::proptest::num::f64::BinarySearch

§

impl Send for rustmax::proptest::num::i8::Any

§

impl Send for rustmax::proptest::num::i8::BinarySearch

§

impl Send for rustmax::proptest::num::i16::Any

§

impl Send for rustmax::proptest::num::i16::BinarySearch

§

impl Send for rustmax::proptest::num::i32::Any

§

impl Send for rustmax::proptest::num::i32::BinarySearch

§

impl Send for rustmax::proptest::num::i64::Any

§

impl Send for rustmax::proptest::num::i64::BinarySearch

§

impl Send for rustmax::proptest::num::i128::Any

§

impl Send for rustmax::proptest::num::i128::BinarySearch

§

impl Send for rustmax::proptest::num::isize::Any

§

impl Send for rustmax::proptest::num::isize::BinarySearch

§

impl Send for rustmax::proptest::num::u8::Any

§

impl Send for rustmax::proptest::num::u8::BinarySearch

§

impl Send for rustmax::proptest::num::u16::Any

§

impl Send for rustmax::proptest::num::u16::BinarySearch

§

impl Send for rustmax::proptest::num::u32::Any

§

impl Send for rustmax::proptest::num::u32::BinarySearch

§

impl Send for rustmax::proptest::num::u64::Any

§

impl Send for rustmax::proptest::num::u64::BinarySearch

§

impl Send for rustmax::proptest::num::u128::Any

§

impl Send for rustmax::proptest::num::u128::BinarySearch

§

impl Send for rustmax::proptest::num::usize::Any

§

impl Send for rustmax::proptest::num::usize::BinarySearch

§

impl Send for PathParams

§

impl Send for rustmax::proptest::prelude::ProptestConfig

§

impl Send for Probability

§

impl Send for rustmax::proptest::sample::Index

§

impl Send for IndexStrategy

§

impl Send for IndexValueTree

§

impl Send for Selector

§

impl Send for SelectorStrategy

§

impl Send for SelectorValueTree

§

impl Send for SizeRange

§

impl Send for CheckStrategySanityOptions

§

impl Send for StringParam

§

impl Send for MapFailurePersistence

§

impl Send for PersistedSeed

§

impl Send for Reason

§

impl Send for TestRng

§

impl Send for TestRunner

§

impl Send for rustmax::rand::distr::slice::Empty

§

impl Send for Alphanumeric

§

impl Send for Bernoulli

§

impl Send for Open01

§

impl Send for OpenClosed01

§

impl Send for StandardUniform

§

impl Send for UniformChar

§

impl Send for UniformDuration

§

impl Send for UniformUsize

§

impl Send for StepRng

§

impl Send for StdRng

§

impl Send for ChaCha8Core

§

impl Send for ChaCha8Rng

§

impl Send for ChaCha12Core

§

impl Send for ChaCha12Rng

§

impl Send for ChaCha20Core

§

impl Send for ChaCha20Rng

§

impl Send for OsError

§

impl Send for OsRng

§

impl Send for Lcg64Xsh32

§

impl Send for Lcg128CmDxsm64

§

impl Send for Lcg128Xsl64

§

impl Send for Mcg128Xsl64

§

impl Send for ThreadBuilder

§

impl Send for ThreadPool

§

impl Send for ThreadPoolBuildError

§

impl Send for rustmax::regex::bytes::CaptureLocations

§

impl Send for rustmax::regex::bytes::Regex

§

impl Send for rustmax::regex::bytes::RegexBuilder

§

impl Send for rustmax::regex::bytes::RegexSet

§

impl Send for rustmax::regex::bytes::RegexSetBuilder

§

impl Send for rustmax::regex::bytes::SetMatches

§

impl Send for rustmax::regex::bytes::SetMatchesIntoIter

§

impl Send for rustmax::regex::CaptureLocations

§

impl Send for rustmax::regex::Regex

§

impl Send for rustmax::regex::RegexBuilder

§

impl Send for rustmax::regex::RegexSet

§

impl Send for rustmax::regex::RegexSetBuilder

§

impl Send for rustmax::regex::SetMatches

§

impl Send for rustmax::regex::SetMatchesIntoIter

§

impl Send for rustmax::reqwest::blocking::Body

§

impl Send for rustmax::reqwest::blocking::Client

§

impl Send for rustmax::reqwest::blocking::ClientBuilder

§

impl Send for rustmax::reqwest::blocking::Request

§

impl Send for rustmax::reqwest::blocking::RequestBuilder

§

impl Send for rustmax::reqwest::blocking::Response

§

impl Send for rustmax::reqwest::dns::Name

§

impl Send for HeaderName

§

impl Send for HeaderValue

§

impl Send for InvalidHeaderName

§

impl Send for InvalidHeaderValue

§

impl Send for MaxSizeReached

§

impl Send for ToStrError

§

impl Send for Action

§

impl Send for Policy

§

impl Send for rustmax::reqwest::Body

§

impl Send for Certificate

§

impl Send for rustmax::reqwest::Client

§

impl Send for rustmax::reqwest::ClientBuilder

§

impl Send for rustmax::reqwest::Error

§

impl Send for rustmax::reqwest::Identity

§

impl Send for Method

§

impl Send for NoProxy

§

impl Send for Proxy

§

impl Send for rustmax::reqwest::Request

§

impl Send for rustmax::reqwest::RequestBuilder

§

impl Send for rustmax::reqwest::Response

§

impl Send for StatusCode

§

impl Send for rustmax::reqwest::Upgraded

§

impl Send for rustmax::reqwest::Version

§

impl Send for TlsInfo

§

impl Send for rustmax::reqwest::tls::Version

§

impl Send for FilenameCompleter

§

impl Send for rustmax::rustyline::completion::Pair

§

impl Send for rustmax::rustyline::config::Builder

§

impl Send for MatchingBracketHighlighter

§

impl Send for HistoryHinter

§

impl Send for FileHistory

§

impl Send for MemHistory

§

impl Send for LineBuffer

§

impl Send for Changeset

§

impl Send for rustmax::rustyline::Config

§

impl Send for KeyEvent

§

impl Send for Modifiers

§

impl Send for MatchingBracketValidator

§

impl Send for BuildMetadata

§

impl Send for Comparator

§

impl Send for rustmax::semver::Error

§

impl Send for Prerelease

§

impl Send for rustmax::semver::Version

§

impl Send for VersionReq

§

impl Send for IgnoredAny

§

impl Send for rustmax::serde::de::value::Error

§

impl Send for rustmax::serde_json::map::IntoIter

§

impl Send for CompactFormatter

§

impl Send for rustmax::serde_json::Error

§

impl Send for RawValue

§

impl Send for rustmax::serde_json::value::Serializer

§

impl Send for ATerm

§

impl Send for B0

§

impl Send for B1

§

impl Send for Equal

§

impl Send for Greater

§

impl Send for Less

§

impl Send for UTerm

§

impl Send for Z0

§

impl Send for Eager

§

impl Send for rustmax::sha2::digest::block_buffer::Error

§

impl Send for rustmax::sha2::digest::block_buffer::Lazy

§

impl Send for InvalidLength

§

impl Send for InvalidBufferSize

§

impl Send for InvalidOutputSize

§

impl Send for Sha256VarCore

§

impl Send for Sha512VarCore

§

impl Send for Domain

§

impl Send for rustmax::socket2::Protocol

§

impl Send for RecvFlags

§

impl Send for SockAddr

§

impl Send for Socket

§

impl Send for TcpKeepalive

§

impl Send for rustmax::socket2::Type

§

impl Send for End

§

impl Send for Nothing

§

impl Send for rustmax::syn::Error

§

impl Send for PathPersistError

§

impl Send for SpooledTempFile

§

impl Send for rustmax::tempfile::TempDir

§

impl Send for TempPath

§

impl Send for rustmax::tera::ast::Block

§

impl Send for rustmax::tera::ast::Expr

§

impl Send for FilterSection

§

impl Send for Forloop

§

impl Send for FunctionCall

§

impl Send for rustmax::tera::ast::If

§

impl Send for rustmax::tera::ast::In

§

impl Send for LogicExpr

§

impl Send for MacroCall

§

impl Send for MacroDefinition

§

impl Send for MathExpr

§

impl Send for Set

§

impl Send for StringConcat

§

impl Send for Test

§

impl Send for WS

§

impl Send for rustmax::tera::Context

§

impl Send for rustmax::tera::Error

§

impl Send for rustmax::tera::Number

§

impl Send for Template

§

impl Send for Tera

§

impl Send for rustmax::termcolor::Buffer

§

impl Send for BufferWriter

§

impl Send for BufferedStandardStream

§

impl Send for ColorChoiceParseError

§

impl Send for ColorSpec

§

impl Send for ParseColorError

§

impl Send for StandardStream

§

impl Send for rustmax::tokio::fs::DirBuilder

§

impl Send for rustmax::tokio::fs::DirEntry

§

impl Send for rustmax::tokio::fs::File

§

impl Send for rustmax::tokio::fs::OpenOptions

§

impl Send for rustmax::tokio::fs::ReadDir

§

impl Send for DuplexStream

§

impl Send for rustmax::tokio::io::Empty

§

impl Send for Interest

§

impl Send for rustmax::tokio::io::Ready

§

impl Send for rustmax::tokio::io::Repeat

§

impl Send for SimplexStream

§

impl Send for rustmax::tokio::io::Sink

§

impl Send for rustmax::tokio::io::Stderr

§

impl Send for rustmax::tokio::io::Stdin

§

impl Send for rustmax::tokio::io::Stdout

§

impl Send for TryIoError

§

impl Send for rustmax::tokio::net::TcpListener

§

impl Send for TcpSocket

§

impl Send for rustmax::tokio::net::TcpStream

§

impl Send for rustmax::tokio::net::UdpSocket

§

impl Send for rustmax::tokio::net::UnixDatagram

§

impl Send for rustmax::tokio::net::UnixListener

§

impl Send for UnixSocket

§

impl Send for rustmax::tokio::net::UnixStream

§

impl Send for rustmax::tokio::net::tcp::OwnedReadHalf

§

impl Send for rustmax::tokio::net::tcp::OwnedWriteHalf

§

impl Send for rustmax::tokio::net::tcp::ReuniteError

§

impl Send for rustmax::tokio::net::unix::pipe::OpenOptions

§

impl Send for rustmax::tokio::net::unix::pipe::Receiver

§

impl Send for rustmax::tokio::net::unix::pipe::Sender

§

impl Send for rustmax::tokio::net::unix::OwnedReadHalf

§

impl Send for rustmax::tokio::net::unix::OwnedWriteHalf

§

impl Send for rustmax::tokio::net::unix::ReuniteError

§

impl Send for rustmax::tokio::net::unix::SocketAddr

§

impl Send for rustmax::tokio::net::unix::UCred

§

impl Send for rustmax::tokio::process::Child

§

impl Send for rustmax::tokio::process::ChildStderr

§

impl Send for rustmax::tokio::process::ChildStdin

§

impl Send for rustmax::tokio::process::ChildStdout

§

impl Send for rustmax::tokio::process::Command

§

impl Send for rustmax::tokio::runtime::Builder

§

impl Send for rustmax::tokio::runtime::Handle

§

impl Send for Runtime

§

impl Send for RuntimeMetrics

§

impl Send for TryCurrentError

§

impl Send for Signal

§

impl Send for SignalKind

§

impl Send for rustmax::tokio::sync::oneshot::error::RecvError

§

impl Send for AcquireError

§

impl Send for rustmax::tokio::sync::Barrier

§

impl Send for rustmax::tokio::sync::BarrierWaitResult

§

impl Send for Notify

§

impl Send for OwnedSemaphorePermit

§

impl Send for Semaphore

§

impl Send for rustmax::tokio::sync::TryLockError

§

impl Send for rustmax::tokio::sync::watch::error::RecvError

§

impl Send for rustmax::tokio::task::Id

§

impl Send for JoinError

§

impl Send for rustmax::tokio::time::error::Elapsed

§

impl Send for rustmax::tokio::time::error::Error

§

impl Send for rustmax::tokio::time::Instant

§

impl Send for Interval

§

impl Send for Sleep

§

impl Send for rustmax::toml::de::Error

§

impl Send for rustmax::toml::map::IntoIter

§

impl Send for rustmax::toml::ser::Error

§

impl Send for rustmax::toml::value::Date

§

impl Send for Datetime

§

impl Send for DatetimeParseError

§

impl Send for rustmax::toml::value::Time

§

impl Send for Discover

§

impl Send for Closed

§

impl Send for ServiceError

§

impl Send for rustmax::tower::layer::util::Identity

§

impl Send for Rate

§

impl Send for ConcurrencyLimitLayer

§

impl Send for GlobalConcurrencyLimitLayer

§

impl Send for RateLimitLayer

§

impl Send for Cost

§

impl Send for rustmax::tower::load::peak_ewma::Handle

§

impl Send for rustmax::tower::load::pending_requests::Count

§

impl Send for rustmax::tower::load::pending_requests::Handle

§

impl Send for CompleteOnResponse

§

impl Send for Overloaded

§

impl Send for LoadShedLayer

§

impl Send for InvalidBackoff

§

impl Send for TpsBudget

§

impl Send for SpawnReadyLayer

§

impl Send for rustmax::tower::timeout::error::Elapsed

§

impl Send for TimeoutLayer

§

impl Send for None

§

impl Send for GraphemeCursor

§

impl Send for OpaqueOrigin

§

impl Send for Url

§

impl Send for rustmax::walkdir::DirEntry

§

impl Send for rustmax::walkdir::Error

§

impl Send for rustmax::walkdir::IntoIter

§

impl Send for WalkDir

§

impl Send for rustmax::xshell::Error

§

impl Send for Shell

§

impl Send for rustmax::xshell::TempDir

§

impl Send for AllocError

§

impl Send for Global

§

impl Send for Layout

§

impl Send for LayoutError

§

impl Send for System

§

impl Send for TypeId

§

impl Send for CpuidResult

§

impl Send for __m128

§

impl Send for __m128bh

§

impl Send for __m128d

§

impl Send for __m128h

§

impl Send for __m128i

§

impl Send for __m256

§

impl Send for __m256bh

§

impl Send for __m256d

§

impl Send for __m256h

§

impl Send for __m256i

§

impl Send for __m512

§

impl Send for __m512bh

§

impl Send for __m512d

§

impl Send for __m512h

§

impl Send for __m512i

§

impl Send for bf16

§

impl Send for TryFromSliceError

§

impl Send for rustmax::std::ascii::EscapeDefault

§

impl Send for rustmax::std::backtrace::Backtrace

§

impl Send for rustmax::std::backtrace::BacktraceFrame

§

impl Send for BorrowError

§

impl Send for BorrowMutError

§

impl Send for CharTryFromError

§

impl Send for DecodeUtf16Error

§

impl Send for rustmax::std::char::EscapeDebug

§

impl Send for rustmax::std::char::EscapeDefault

§

impl Send for rustmax::std::char::EscapeUnicode

§

impl Send for ParseCharError

§

impl Send for ToLowercase

§

impl Send for ToUppercase

§

impl Send for TryFromCharError

§

impl Send for UnorderedKeyError

§

impl Send for TryReserveError

§

impl Send for JoinPathsError

§

impl Send for CStr

§

impl Send for CString

§

impl Send for FromBytesUntilNulError

§

impl Send for FromBytesWithNulError

§

impl Send for FromVecWithNulError

§

impl Send for IntoStringError

§

impl Send for NulError

§

impl Send for rustmax::std::ffi::OsStr

§

impl Send for OsString

§

impl Send for rustmax::std::fmt::Error

§

impl Send for rustmax::std::fs::DirBuilder

§

impl Send for rustmax::std::fs::DirEntry

§

impl Send for rustmax::std::fs::File

§

impl Send for FileTimes

§

impl Send for FileType

§

impl Send for rustmax::std::fs::Metadata

§

impl Send for rustmax::std::fs::OpenOptions

§

impl Send for Permissions

§

impl Send for rustmax::std::fs::ReadDir

§

impl Send for DefaultHasher

§

impl Send for rustmax::std::hash::RandomState

§

impl Send for SipHasher

§

impl Send for ReturnToArg

§

impl Send for UnwindActionArg

§

impl Send for rustmax::std::io::Empty

§

impl Send for rustmax::std::io::Error

§

impl Send for rustmax::std::io::Repeat

§

impl Send for rustmax::std::io::Sink

§

impl Send for rustmax::std::io::Stderr

§

impl Send for rustmax::std::io::Stdin

§

impl Send for rustmax::std::io::Stdout

§

impl Send for WriterPanicked

§

impl Send for Assume

§

impl Send for AddrParseError

§

impl Send for IntoIncoming

§

impl Send for Ipv4Addr

§

impl Send for Ipv6Addr

§

impl Send for SocketAddrV4

§

impl Send for SocketAddrV6

§

impl Send for rustmax::std::net::TcpListener

§

impl Send for rustmax::std::net::TcpStream

§

impl Send for rustmax::std::net::UdpSocket

§

impl Send for ParseFloatError

§

impl Send for ParseIntError

§

impl Send for TryFromIntError

§

impl Send for RangeFull

§

impl Send for OwnedFd

§

impl Send for PidFd

§

impl Send for rustmax::std::os::linux::raw::stat

§

impl Send for rustmax::std::os::unix::net::SocketAddr

§

impl Send for SocketCred

§

impl Send for rustmax::std::os::unix::net::UCred

§

impl Send for rustmax::std::os::unix::net::UnixDatagram

§

impl Send for rustmax::std::os::unix::net::UnixListener

§

impl Send for rustmax::std::os::unix::net::UnixStream

§

impl Send for rustmax::std::path::Path

§

impl Send for PathBuf

§

impl Send for StripPrefixError

§

impl Send for PipeReader

§

impl Send for PipeWriter

§

impl Send for rustmax::std::process::Child

§

impl Send for rustmax::std::process::ChildStderr

§

impl Send for rustmax::std::process::ChildStdin

§

impl Send for rustmax::std::process::ChildStdout

§

impl Send for rustmax::std::process::Command

§

impl Send for ExitCode

§

impl Send for ExitStatus

§

impl Send for ExitStatusError

§

impl Send for Output

§

impl Send for Stdio

§

impl Send for rustmax::std::ptr::Alignment

§

impl Send for DefaultRandomSource

§

impl Send for ParseBoolError

§

impl Send for Utf8Error

§

impl Send for FromUtf8Error

§

impl Send for FromUtf16Error

§

impl Send for String

§

impl Send for AtomicBool

§

impl Send for AtomicI8

§

impl Send for AtomicI16

§

impl Send for AtomicI32

§

impl Send for AtomicI64

§

impl Send for AtomicIsize

§

impl Send for AtomicU8

§

impl Send for AtomicU16

§

impl Send for AtomicU32

§

impl Send for AtomicU64

§

impl Send for AtomicUsize

§

impl Send for rustmax::std::sync::mpsc::RecvError

§

impl Send for rustmax::std::sync::Barrier

§

impl Send for rustmax::std::sync::BarrierWaitResult

§

impl Send for Condvar

§

impl Send for rustmax::std::sync::Once

§

impl Send for OnceState

§

impl Send for WaitTimeoutResult

§

impl Send for RawWakerVTable

§

impl Send for AccessError

§

impl Send for rustmax::std::thread::Builder

§

impl Send for Thread

§

impl Send for ThreadId

§

impl Send for Duration

§

impl Send for rustmax::std::time::Instant

§

impl Send for SystemTime

§

impl Send for SystemTimeError

§

impl Send for TryFromFloatSecsError

§

impl Send for PhantomPinned

§

impl Send for __c_anonymous_iwreq

§

impl Send for __c_anonymous_ptp_perout_request_1

§

impl Send for __c_anonymous_ptp_perout_request_2

§

impl Send for __c_anonymous_ptrace_syscall_info_data

§

impl Send for __c_anonymous_sockaddr_can_can_addr

§

impl Send for __c_anonymous_xsk_tx_metadata_union

§

impl Send for tpacket_bd_header_u

§

impl Send for tpacket_req_u

§

impl Send for Big8x3

§

impl Send for Big32x40

§

impl Send for Decoded

§

impl Send for FullDecoded

§

impl Send for InvertedUTerm

§

impl Send for LitKind

§

impl Send for MustAbort

§

impl Send for Number

§

impl Send for PanicMessage

§

impl Send for ProcMacro

§

impl Send for SameThread

§

impl Send for Sign

§

impl Send for TryCaptureWithDebug

§

impl Send for TryCaptureWithoutDebug

§

impl<'a> !Send for rustmax::anyhow::Chain<'a>

§

impl<'a> !Send for Source<'a>

§

impl<'a> !Send for PanicInfo<'a>

§

impl<'a> !Send for rustmax::core::panic::PanicMessage<'a>

§

impl<'a> !Send for SelectedOperation<'a>

§

impl<'a> !Send for Record<'a>

§

impl<'a> !Send for RecordBuilder<'a>

§

impl<'a> !Send for ResultCacheKey<'a>

§

impl<'a> !Send for BroadcastContext<'a>

§

impl<'a> !Send for rustmax::syn::buffer::Cursor<'a>

§

impl<'a> !Send for ParseNestedMeta<'a>

§

impl<'a> !Send for Lookahead1<'a>

§

impl<'a> !Send for ParseBuffer<'a>

§

impl<'a> !Send for ImplGenerics<'a>

§

impl<'a> !Send for Turbofish<'a>

§

impl<'a> !Send for TypeGenerics<'a>

§

impl<'a> !Send for StandardStreamLock<'a>

§

impl<'a> !Send for EnterGuard<'a>

§

impl<'a> !Send for ParseOptions<'a>

§

impl<'a> !Send for rustmax::xshell::Cmd<'a>

§

impl<'a> !Send for PushDir<'a>

§

impl<'a> !Send for PushEnv<'a>

§

impl<'a> !Send for rustmax::std::error::Request<'a>

§

impl<'a> !Send for rustmax::std::fmt::Formatter<'a>

§

impl<'a> !Send for StderrLock<'a>

§

impl<'a> !Send for StdinLock<'a>

§

impl<'a> !Send for StdoutLock<'a>

§

impl<'a> !Send for PanicHookInfo<'a>

§

impl<'a> !Send for rustmax::std::task::Context<'a>

§

impl<'a> !Send for ContextBuilder<'a>

§

impl<'a> !Send for BridgeConfig<'a>

§

impl<'a> Send for BytesOrWideString<'a>

§

impl<'a> Send for rustmax::chrono::format::Item<'a>

§

impl<'a> Send for IndexVecIter<'a>

§

impl<'a> Send for Unexpected<'a>

§

impl<'a> Send for rustmax::serde_json::map::Entry<'a>

§

impl<'a> Send for rustmax::toml::map::Entry<'a>

§

impl<'a> Send for AncillaryData<'a>

§

impl<'a> Send for Component<'a>

§

impl<'a> Send for Prefix<'a>

§

impl<'a> Send for Utf8Pattern<'a>

§

impl<'a> Send for RawPathParamsIter<'a>

§

impl<'a> Send for SymbolName<'a>

§

impl<'a> Send for AttributeInfo<'a>

§

impl<'a> Send for DeriveInfo<'a>

§

impl<'a> Send for FieldInfo<'a>

§

impl<'a> Send for ItemInfo<'a>

§

impl<'a> Send for StrftimeItems<'a>

§

impl<'a> Send for IdsRef<'a>

§

impl<'a> Send for Indices<'a>

§

impl<'a> Send for RawValues<'a>

§

impl<'a> Send for Env<'a>

§

impl<'a> Send for WakerRef<'a>

§

impl<'a> Send for rustmax::hyper::rt::ReadBuf<'a>

§

impl<'a> Send for ReadBufCursor<'a>

§

impl<'a> Send for SpanArithmetic<'a>

§

impl<'a> Send for SpanCompare<'a>

§

impl<'a> Send for SpanRelativeTo<'a>

§

impl<'a> Send for SpanRound<'a>

§

impl<'a> Send for SpanTotal<'a>

§

impl<'a> Send for ZonedDifference<'a>

§

impl<'a> Send for rustmax::log::Metadata<'a>

§

impl<'a> Send for MetadataBuilder<'a>

§

impl<'a> Send for MimeIter<'a>

§

impl<'a> Send for rustmax::mime::Name<'a>

§

impl<'a> Send for Params<'a>

§

impl<'a> Send for U32Digits<'a>

§

impl<'a> Send for U64Digits<'a>

§

impl<'a> Send for CharStrategy<'a>

§

impl<'a> Send for rustmax::rayon::string::Drain<'a>

§

impl<'a> Send for rustmax::regex::bytes::SetMatchesIter<'a>

§

impl<'a> Send for rustmax::regex::SetMatchesIter<'a>

§

impl<'a> Send for Attempt<'a>

§

impl<'a> Send for SearchResult<'a>

§

impl<'a> Send for SliceRead<'a>

§

impl<'a> Send for StrRead<'a>

§

impl<'a> Send for rustmax::serde_json::map::Iter<'a>

§

impl<'a> Send for rustmax::serde_json::map::IterMut<'a>

§

impl<'a> Send for rustmax::serde_json::map::Keys<'a>

§

impl<'a> Send for rustmax::serde_json::map::OccupiedEntry<'a>

§

impl<'a> Send for rustmax::serde_json::map::VacantEntry<'a>

§

impl<'a> Send for rustmax::serde_json::map::Values<'a>

§

impl<'a> Send for rustmax::serde_json::map::ValuesMut<'a>

§

impl<'a> Send for PrettyFormatter<'a>

§

impl<'a> Send for MaybeUninitSlice<'a>

§

impl<'a> Send for HyperlinkSpec<'a>

§

impl<'a> Send for rustmax::tokio::io::ReadBuf<'a>

§

impl<'a> Send for rustmax::tokio::net::tcp::ReadHalf<'a>

§

impl<'a> Send for rustmax::tokio::net::tcp::WriteHalf<'a>

§

impl<'a> Send for rustmax::tokio::net::unix::ReadHalf<'a>

§

impl<'a> Send for rustmax::tokio::net::unix::WriteHalf<'a>

§

impl<'a> Send for SemaphorePermit<'a>

§

impl<'a> Send for ValueDeserializer<'a>

§

impl<'a> Send for rustmax::toml::map::Iter<'a>

§

impl<'a> Send for rustmax::toml::map::IterMut<'a>

§

impl<'a> Send for rustmax::toml::map::Keys<'a>

§

impl<'a> Send for rustmax::toml::map::OccupiedEntry<'a>

§

impl<'a> Send for rustmax::toml::map::VacantEntry<'a>

§

impl<'a> Send for rustmax::toml::map::Values<'a>

§

impl<'a> Send for rustmax::toml::Deserializer<'a>

§

impl<'a> Send for GraphemeIndices<'a>

§

impl<'a> Send for Graphemes<'a>

§

impl<'a> Send for USentenceBoundIndices<'a>

§

impl<'a> Send for USentenceBounds<'a>

§

impl<'a> Send for UWordBoundIndices<'a>

§

impl<'a> Send for UWordBounds<'a>

§

impl<'a> Send for UnicodeSentences<'a>

§

impl<'a> Send for UnicodeWordIndices<'a>

§

impl<'a> Send for UnicodeWords<'a>

§

impl<'a> Send for ByteSerialize<'a>

§

impl<'a> Send for Parse<'a>

§

impl<'a> Send for ParseIntoOwned<'a>

§

impl<'a> Send for PathSegmentsMut<'a>

§

impl<'a> Send for UrlQuery<'a>

§

impl<'a> Send for SplitPaths<'a>

§

impl<'a> Send for rustmax::std::ffi::os_str::Display<'a>

§

impl<'a> Send for BorrowedCursor<'a>

§

impl<'a> Send for rustmax::std::net::Incoming<'a>

§

impl<'a> Send for rustmax::std::os::unix::net::Incoming<'a>

§

impl<'a> Send for Messages<'a>

§

impl<'a> Send for ScmCredentials<'a>

§

impl<'a> Send for ScmRights<'a>

§

impl<'a> Send for SocketAncillary<'a>

§

impl<'a> Send for rustmax::std::panic::Location<'a>

§

impl<'a> Send for Ancestors<'a>

§

impl<'a> Send for Components<'a>

§

impl<'a> Send for rustmax::std::path::Display<'a>

§

impl<'a> Send for rustmax::std::path::Iter<'a>

§

impl<'a> Send for PrefixComponent<'a>

§

impl<'a> Send for CommandArgs<'a>

§

impl<'a> Send for CommandEnvs<'a>

§

impl<'a> Send for EscapeAscii<'a>

§

impl<'a> Send for CharSearcher<'a>

§

impl<'a> Send for rustmax::std::str::Bytes<'a>

§

impl<'a> Send for rustmax::std::str::CharIndices<'a>

§

impl<'a> Send for rustmax::std::str::Chars<'a>

§

impl<'a> Send for rustmax::std::str::EncodeUtf16<'a>

§

impl<'a> Send for rustmax::std::str::EscapeDebug<'a>

§

impl<'a> Send for rustmax::std::str::EscapeDefault<'a>

§

impl<'a> Send for rustmax::std::str::EscapeUnicode<'a>

§

impl<'a> Send for rustmax::std::str::Lines<'a>

§

impl<'a> Send for LinesAny<'a>

§

impl<'a> Send for rustmax::std::str::SplitAsciiWhitespace<'a>

§

impl<'a> Send for rustmax::std::str::SplitWhitespace<'a>

§

impl<'a> Send for Utf8Chunk<'a>

§

impl<'a> Send for Utf8Chunks<'a>

§

impl<'a> Send for Formatted<'a>

§

impl<'a> Send for Part<'a>

§

impl<'a, 'b> !Send for BacktraceFmt<'a, 'b>

§

impl<'a, 'b> !Send for DebugList<'a, 'b>

§

impl<'a, 'b> !Send for DebugMap<'a, 'b>

§

impl<'a, 'b> !Send for DebugSet<'a, 'b>

§

impl<'a, 'b> !Send for DebugStruct<'a, 'b>

§

impl<'a, 'b> !Send for DebugTuple<'a, 'b>

§

impl<'a, 'b> Send for rustmax::tempfile::Builder<'a, 'b>

§

impl<'a, 'b> Send for CharSliceSearcher<'a, 'b>

§

impl<'a, 'b> Send for StrSearcher<'a, 'b>

§

impl<'a, 'b, const N: usize> Send for CharArrayRefSearcher<'a, 'b, N>

§

impl<'a, 'e, E> Send for Base64Display<'a, 'e, E>

§

impl<'a, 'f> !Send for VaList<'a, 'f>

§

impl<'a, A> Send for rustmax::std::option::Iter<'a, A>
where A: Sync,

§

impl<'a, A> Send for rustmax::std::option::IterMut<'a, A>
where A: Send,

§

impl<'a, B> Send for Cow<'a, B>
where <B as ToOwned>::Owned: Send, B: Sync + ?Sized,

§

impl<'a, B, S> Send for RouterAsService<'a, B, S>
where B: Send,

§

impl<'a, E> Send for BytesDeserializer<'a, E>
where E: Send,

§

impl<'a, E> Send for CowStrDeserializer<'a, E>
where E: Send,

§

impl<'a, E> Send for StrDeserializer<'a, E>
where E: Send,

§

impl<'a, F> Send for CharPredicateSearcher<'a, F>
where F: Send,

§

impl<'a, F, O> Send for Fill<'a, F, O>
where F: Send, O: Send,

§

impl<'a, Fut> Send for rustmax::futures::prelude::stream::futures_unordered::Iter<'a, Fut>
where Fut: Send,

§

impl<'a, Fut> Send for rustmax::futures::prelude::stream::futures_unordered::IterMut<'a, Fut>
where Fut: Send,

§

impl<'a, I> !Send for Chunk<'a, I>

§

impl<'a, I> !Send for rustmax::itertools::Chunks<'a, I>

§

impl<'a, I> Send for Format<'a, I>
where I: Send,

§

impl<'a, I> Send for ByRefSized<'a, I>
where I: Send,

§

impl<'a, I, A> Send for Splice<'a, I, A>
where I: Send, <I as Iterator>::Item: Send, A: Send,

§

impl<'a, I, E> Send for ProcessResults<'a, I, E>
where I: Send, E: Send,

§

impl<'a, I, F> Send for FormatWith<'a, I, F>
where I: Send, F: Send,

§

impl<'a, I, F> Send for PeekingTakeWhile<'a, I, F>
where F: Send, I: Send,

§

impl<'a, I, F> Send for TakeWhileRef<'a, I, F>
where F: Send, I: Send,

§

impl<'a, K> Send for rustmax::std::collections::btree_set::Cursor<'a, K>
where K: Sync,

§

impl<'a, K> Send for rustmax::std::collections::hash_set::Drain<'a, K>
where K: Send,

§

impl<'a, K> Send for rustmax::std::collections::hash_set::Iter<'a, K>
where K: Sync,

§

impl<'a, K, A> Send for rustmax::std::collections::btree_set::CursorMut<'a, K, A>
where A: Send, K: Send,

§

impl<'a, K, A> Send for rustmax::std::collections::btree_set::CursorMutKey<'a, K, A>
where A: Send, K: Send,

§

impl<'a, K, F> Send for rustmax::std::collections::hash_set::ExtractIf<'a, K, F>
where F: Send, K: Send,

§

impl<'a, K, I, F> !Send for rustmax::itertools::Group<'a, K, I, F>

§

impl<'a, K, I, F> !Send for Groups<'a, K, I, F>

§

impl<'a, K, V> Send for rustmax::std::collections::hash_map::Entry<'a, K, V>
where K: Send, V: Send,

§

impl<'a, K, V> Send for rustmax::rayon::collections::btree_map::Iter<'a, K, V>

§

impl<'a, K, V> Send for rustmax::rayon::collections::btree_map::IterMut<'a, K, V>

§

impl<'a, K, V> Send for rustmax::rayon::collections::hash_map::Drain<'a, K, V>

§

impl<'a, K, V> Send for rustmax::rayon::collections::hash_map::Iter<'a, K, V>

§

impl<'a, K, V> Send for rustmax::rayon::collections::hash_map::IterMut<'a, K, V>

§

impl<'a, K, V> Send for rustmax::std::collections::btree_map::Cursor<'a, K, V>
where K: Sync, V: Sync,

§

impl<'a, K, V> Send for rustmax::std::collections::btree_map::Iter<'a, K, V>
where K: Sync, V: Sync,

§

impl<'a, K, V> Send for rustmax::std::collections::btree_map::IterMut<'a, K, V>
where K: Send, V: Send,

§

impl<'a, K, V> Send for rustmax::std::collections::btree_map::Keys<'a, K, V>
where K: Sync, V: Sync,

§

impl<'a, K, V> Send for rustmax::std::collections::btree_map::Range<'a, K, V>
where K: Sync, V: Sync,

§

impl<'a, K, V> Send for RangeMut<'a, K, V>
where K: Send, V: Send,

§

impl<'a, K, V> Send for rustmax::std::collections::btree_map::Values<'a, K, V>
where K: Sync, V: Sync,

§

impl<'a, K, V> Send for rustmax::std::collections::btree_map::ValuesMut<'a, K, V>
where K: Send, V: Send,

§

impl<'a, K, V> Send for rustmax::std::collections::hash_map::Drain<'a, K, V>
where K: Send, V: Send,

§

impl<'a, K, V> Send for rustmax::std::collections::hash_map::Iter<'a, K, V>
where K: Sync, V: Sync,

§

impl<'a, K, V> Send for rustmax::std::collections::hash_map::IterMut<'a, K, V>
where K: Send, V: Send,

§

impl<'a, K, V> Send for rustmax::std::collections::hash_map::Keys<'a, K, V>
where K: Sync, V: Sync,

§

impl<'a, K, V> Send for rustmax::std::collections::hash_map::OccupiedEntry<'a, K, V>
where K: Send, V: Send,

§

impl<'a, K, V> Send for rustmax::std::collections::hash_map::OccupiedError<'a, K, V>
where V: Send, K: Send,

§

impl<'a, K, V> Send for rustmax::std::collections::hash_map::VacantEntry<'a, K, V>
where K: Send, V: Send,

§

impl<'a, K, V> Send for rustmax::std::collections::hash_map::Values<'a, K, V>
where K: Sync, V: Sync,

§

impl<'a, K, V> Send for rustmax::std::collections::hash_map::ValuesMut<'a, K, V>
where K: Send, V: Send,

§

impl<'a, K, V, A> Send for rustmax::std::collections::btree_map::Entry<'a, K, V, A>
where K: Send, A: Send, V: Send,

§

impl<'a, K, V, A> Send for rustmax::std::collections::btree_map::CursorMut<'a, K, V, A>
where A: Send, K: Send, V: Send,

§

impl<'a, K, V, A> Send for rustmax::std::collections::btree_map::CursorMutKey<'a, K, V, A>
where A: Send, K: Send, V: Send,

§

impl<'a, K, V, A> Send for rustmax::std::collections::btree_map::OccupiedEntry<'a, K, V, A>
where A: Send, K: Send, V: Send,

§

impl<'a, K, V, A> Send for rustmax::std::collections::btree_map::OccupiedError<'a, K, V, A>
where V: Send, A: Send, K: Send,

§

impl<'a, K, V, A> Send for rustmax::std::collections::btree_map::VacantEntry<'a, K, V, A>
where K: Send, A: Send, V: Send,

§

impl<'a, K, V, F> Send for rustmax::std::collections::hash_map::ExtractIf<'a, K, V, F>
where F: Send, K: Send, V: Send,

§

impl<'a, K, V, F, A> Send for rustmax::std::collections::btree_map::ExtractIf<'a, K, V, F, A>
where F: Send, A: Send, K: Send, V: Send,

§

impl<'a, K, V, S> Send for RawEntryMut<'a, K, V, S>
where K: Send, V: Send, S: Send + Sync,

§

impl<'a, K, V, S> Send for RawEntryBuilder<'a, K, V, S>
where S: Sync, K: Sync, V: Sync,

§

impl<'a, K, V, S> Send for RawEntryBuilderMut<'a, K, V, S>
where S: Send, K: Send, V: Send,

§

impl<'a, K, V, S> Send for RawOccupiedEntryMut<'a, K, V, S>
where K: Send, V: Send, S: Send,

§

impl<'a, K, V, S> Send for RawVacantEntryMut<'a, K, V, S>
where S: Sync, K: Send, V: Send,

§

impl<'a, L> Send for IncomingStream<'a, L>
where <L as Listener>::Io: Sync,

§

impl<'a, M, Request> Send for AsService<'a, M, Request>
where M: Send, Request: Send,

§

impl<'a, P> Send for rustmax::std::str::MatchIndices<'a, P>
where <P as Pattern>::Searcher<'a>: Send,

§

impl<'a, P> Send for rustmax::std::str::Matches<'a, P>
where <P as Pattern>::Searcher<'a>: Send,

§

impl<'a, P> Send for RMatchIndices<'a, P>
where <P as Pattern>::Searcher<'a>: Send,

§

impl<'a, P> Send for RMatches<'a, P>
where <P as Pattern>::Searcher<'a>: Send,

§

impl<'a, P> Send for rustmax::std::str::RSplit<'a, P>
where <P as Pattern>::Searcher<'a>: Send,

§

impl<'a, P> Send for rustmax::std::str::RSplitN<'a, P>
where <P as Pattern>::Searcher<'a>: Send,

§

impl<'a, P> Send for RSplitTerminator<'a, P>
where <P as Pattern>::Searcher<'a>: Send,

§

impl<'a, P> Send for rustmax::std::str::Split<'a, P>
where <P as Pattern>::Searcher<'a>: Send,

§

impl<'a, P> Send for rustmax::std::str::SplitInclusive<'a, P>
where <P as Pattern>::Searcher<'a>: Send,

§

impl<'a, P> Send for rustmax::std::str::SplitN<'a, P>
where <P as Pattern>::Searcher<'a>: Send,

§

impl<'a, P> Send for rustmax::std::str::SplitTerminator<'a, P>
where <P as Pattern>::Searcher<'a>: Send,

§

impl<'a, R> Send for FillBuf<'a, R>
where R: Send + ?Sized,

§

impl<'a, R> Send for Read<'a, R>
where R: Send + ?Sized,

§

impl<'a, R> Send for ReadExact<'a, R>
where R: Send + ?Sized,

§

impl<'a, R> Send for ReadLine<'a, R>
where R: Send + ?Sized,

§

impl<'a, R> Send for ReadToEnd<'a, R>
where R: Send + ?Sized,

§

impl<'a, R> Send for ReadToString<'a, R>
where R: Send + ?Sized,

§

impl<'a, R> Send for ReadUntil<'a, R>
where R: Send + ?Sized,

§

impl<'a, R> Send for ReadVectored<'a, R>
where R: Send + ?Sized,

§

impl<'a, R> Send for SeeKRelative<'a, R>
where R: Send,

§

impl<'a, R> Send for RngReadAdapter<'a, R>
where R: Send + ?Sized,

§

impl<'a, R> Send for rustmax::regex::bytes::ReplacerRef<'a, R>
where R: Send + ?Sized,

§

impl<'a, R> Send for rustmax::regex::ReplacerRef<'a, R>
where R: Send + ?Sized,

§

impl<'a, R, W> Send for Copy<'a, R, W>
where R: Send, W: Send + ?Sized,

§

impl<'a, R, W> Send for CopyBuf<'a, R, W>
where R: Send, W: Send + ?Sized,

§

impl<'a, R, W> Send for CopyBufAbortable<'a, R, W>
where R: Send, W: Send + ?Sized,

§

impl<'a, S> Send for Seek<'a, S>
where S: Send + ?Sized,

§

impl<'a, S, T> Send for SliceChooseIter<'a, S, T>
where S: Sync + ?Sized, T: Send,

§

impl<'a, Si, Item> Send for rustmax::futures::prelude::sink::Close<'a, Si, Item>
where Si: Send + ?Sized,

§

impl<'a, Si, Item> Send for Feed<'a, Si, Item>
where Si: Send + ?Sized, Item: Send,

§

impl<'a, Si, Item> Send for rustmax::futures::prelude::sink::Flush<'a, Si, Item>
where Si: Send + ?Sized,

§

impl<'a, Si, Item> Send for Send<'a, Si, Item>
where Si: Send + ?Sized, Item: Send,

§

impl<'a, Si, St> Send for SendAll<'a, Si, St>
where Si: Send + ?Sized, <St as TryStream>::Ok: Send, St: Send + ?Sized,

§

impl<'a, St> Send for rustmax::futures::prelude::stream::select_all::Iter<'a, St>
where St: Send,

§

impl<'a, St> Send for rustmax::futures::prelude::stream::select_all::IterMut<'a, St>
where St: Send,

§

impl<'a, St> Send for rustmax::futures::prelude::stream::Next<'a, St>
where St: Send + ?Sized,

§

impl<'a, St> Send for rustmax::futures::prelude::stream::Peek<'a, St>
where St: Send, <St as Stream>::Item: Send,

§

impl<'a, St> Send for rustmax::futures::prelude::stream::PeekMut<'a, St>
where St: Send, <St as Stream>::Item: Send,

§

impl<'a, St> Send for SelectNextSome<'a, St>
where St: Send + ?Sized,

§

impl<'a, St> Send for TryNext<'a, St>
where St: Send + ?Sized,

§

impl<'a, St, F> Send for NextIf<'a, St, F>
where F: Send, St: Send, <St as Stream>::Item: Send,

§

impl<'a, St, T> Send for NextIfEq<'a, St, T>
where T: Sync + ?Sized, <St as Stream>::Item: Send, St: Send,

§

impl<'a, T> !Send for ShardedLockReadGuard<'a, T>

§

impl<'a, T> !Send for ShardedLockWriteGuard<'a, T>

§

impl<'a, T> !Send for LocalFutureObj<'a, T>

§

impl<'a, T> !Send for rustmax::syn::punctuated::Iter<'a, T>

§

impl<'a, T> !Send for rustmax::syn::punctuated::IterMut<'a, T>

§

impl<'a, T> !Send for rustmax::tokio::sync::watch::Ref<'a, T>

§

impl<'a, T> !Send for rustmax::url::form_urlencoded::Serializer<'a, T>

§

impl<'a, T> !Send for rustmax::std::sync::mpsc::Iter<'a, T>

§

impl<'a, T> !Send for rustmax::std::sync::mpsc::TryIter<'a, T>

§

impl<'a, T> Send for rustmax::reqwest::header::Entry<'a, T>
where T: Send,

§

impl<'a, T> Send for ValuesRef<'a, T>

§

impl<'a, T> Send for rustmax::crossbeam::channel::Iter<'a, T>
where T: Send,

§

impl<'a, T> Send for rustmax::crossbeam::channel::TryIter<'a, T>
where T: Send,

§

impl<'a, T> Send for rustmax::cxx_build::vector::Iter<'a, T>
where T: Sync,

§

impl<'a, T> Send for rustmax::cxx_build::vector::IterMut<'a, T>
where T: Send,

§

impl<'a, T> Send for Cancellation<'a, T>
where T: Send,

§

impl<'a, T> Send for Choose<'a, T>
where T: Sync,

§

impl<'a, T> Send for rustmax::rayon::collections::binary_heap::Drain<'a, T>

§

impl<'a, T> Send for rustmax::rayon::collections::binary_heap::Iter<'a, T>

§

impl<'a, T> Send for rustmax::rayon::collections::btree_set::Iter<'a, T>

§

impl<'a, T> Send for rustmax::rayon::collections::hash_set::Drain<'a, T>

§

impl<'a, T> Send for rustmax::rayon::collections::hash_set::Iter<'a, T>

§

impl<'a, T> Send for rustmax::rayon::collections::linked_list::Iter<'a, T>

§

impl<'a, T> Send for rustmax::rayon::collections::linked_list::IterMut<'a, T>

§

impl<'a, T> Send for rustmax::rayon::collections::vec_deque::Drain<'a, T>

§

impl<'a, T> Send for rustmax::rayon::collections::vec_deque::Iter<'a, T>

§

impl<'a, T> Send for rustmax::rayon::collections::vec_deque::IterMut<'a, T>

§

impl<'a, T> Send for rustmax::rayon::option::Iter<'a, T>

§

impl<'a, T> Send for rustmax::rayon::option::IterMut<'a, T>

§

impl<'a, T> Send for rustmax::rayon::result::Iter<'a, T>

§

impl<'a, T> Send for rustmax::rayon::result::IterMut<'a, T>

§

impl<'a, T> Send for GetAll<'a, T>
where T: Sync,

§

impl<'a, T> Send for rustmax::reqwest::header::Keys<'a, T>
where T: Sync,

§

impl<'a, T> Send for rustmax::reqwest::header::OccupiedEntry<'a, T>
where T: Send,

§

impl<'a, T> Send for rustmax::reqwest::header::VacantEntry<'a, T>
where T: Send,

§

impl<'a, T> Send for ValueIter<'a, T>
where T: Sync,

§

impl<'a, T> Send for rustmax::reqwest::header::Values<'a, T>
where T: Sync,

§

impl<'a, T> Send for rustmax::reqwest::header::ValuesMut<'a, T>
where T: Send,

§

impl<'a, T> Send for AsyncFdReadyGuard<'a, T>
where T: Sync,

§

impl<'a, T> Send for AsyncFdReadyMutGuard<'a, T>
where T: Send,

§

impl<'a, T> Send for Permit<'a, T>
where T: Send,

§

impl<'a, T> Send for PermitIterator<'a, T>
where T: Send,

§

impl<'a, T> Send for rustmax::tokio::sync::MutexGuard<'a, T>
where T: Send + ?Sized,

§

impl<'a, T> Send for rustmax::std::collections::binary_heap::Iter<'a, T>
where T: Sync,

§

impl<'a, T> Send for rustmax::std::collections::btree_set::Iter<'a, T>
where T: Sync,

§

impl<'a, T> Send for rustmax::std::collections::btree_set::Range<'a, T>
where T: Sync,

§

impl<'a, T> Send for rustmax::std::collections::btree_set::SymmetricDifference<'a, T>
where T: Sync,

§

impl<'a, T> Send for rustmax::std::collections::btree_set::Union<'a, T>
where T: Sync,

§

impl<'a, T> Send for rustmax::std::collections::vec_deque::Iter<'a, T>
where T: Sync,

§

impl<'a, T> Send for rustmax::std::collections::vec_deque::IterMut<'a, T>
where T: Send,

§

impl<'a, T> Send for rustmax::std::result::Iter<'a, T>
where T: Sync,

§

impl<'a, T> Send for rustmax::std::result::IterMut<'a, T>
where T: Send,

§

impl<'a, T> Send for rustmax::std::slice::Chunks<'a, T>
where T: Sync,

§

impl<'a, T> Send for rustmax::std::slice::ChunksExact<'a, T>
where T: Sync,

§

impl<'a, T> Send for rustmax::std::slice::RChunks<'a, T>
where T: Sync,

§

impl<'a, T> Send for rustmax::std::slice::RChunksExact<'a, T>
where T: Sync,

§

impl<'a, T> Send for rustmax::std::slice::Windows<'a, T>
where T: Sync,

§

impl<'a, T> Send for rustmax::std::sync::mpmc::Iter<'a, T>
where T: Send,

§

impl<'a, T> Send for rustmax::std::sync::mpmc::TryIter<'a, T>
where T: Send,

§

impl<'a, T, A> Send for rustmax::std::collections::binary_heap::Drain<'a, T, A>
where T: Send, A: Send,

§

impl<'a, T, A> Send for DrainSorted<'a, T, A>
where A: Send, T: Send,

§

impl<'a, T, A> Send for rustmax::std::collections::binary_heap::PeekMut<'a, T, A>
where A: Send, T: Send,

§

impl<'a, T, A> Send for rustmax::std::collections::btree_set::Difference<'a, T, A>
where T: Sync, A: Sync,

§

impl<'a, T, A> Send for rustmax::std::collections::btree_set::Intersection<'a, T, A>
where T: Sync, A: Sync,

§

impl<'a, T, F, A = Global> !Send for rustmax::std::collections::linked_list::ExtractIf<'a, T, F, A>

§

impl<'a, T, F, A> Send for rustmax::std::collections::btree_set::ExtractIf<'a, T, F, A>
where F: Send, A: Send, T: Send,

§

impl<'a, T, F, A> Send for rustmax::std::vec::ExtractIf<'a, T, F, A>
where F: Send, A: Send, T: Send,

§

impl<'a, T, P> Send for Pairs<'a, T, P>
where T: Sync, P: Sync,

§

impl<'a, T, P> Send for PairsMut<'a, T, P>
where T: Send, P: Send,

§

impl<'a, T, P> Send for rustmax::std::slice::ChunkBy<'a, T, P>
where P: Send, T: Sync,

§

impl<'a, T, P> Send for rustmax::std::slice::ChunkByMut<'a, T, P>
where P: Send, T: Send,

§

impl<'a, T, P> Send for rustmax::std::slice::RSplit<'a, T, P>
where P: Send, T: Sync,

§

impl<'a, T, P> Send for RSplitMut<'a, T, P>
where P: Send, T: Send,

§

impl<'a, T, P> Send for rustmax::std::slice::RSplitN<'a, T, P>
where P: Send, T: Sync,

§

impl<'a, T, P> Send for RSplitNMut<'a, T, P>
where P: Send, T: Send,

§

impl<'a, T, P> Send for rustmax::std::slice::Split<'a, T, P>
where P: Send, T: Sync,

§

impl<'a, T, P> Send for rustmax::std::slice::SplitInclusive<'a, T, P>
where P: Send, T: Sync,

§

impl<'a, T, P> Send for rustmax::std::slice::SplitInclusiveMut<'a, T, P>
where P: Send, T: Send,

§

impl<'a, T, P> Send for rustmax::std::slice::SplitMut<'a, T, P>
where P: Send, T: Send,

§

impl<'a, T, P> Send for rustmax::std::slice::SplitN<'a, T, P>
where P: Send, T: Sync,

§

impl<'a, T, P> Send for SplitNMut<'a, T, P>
where P: Send, T: Send,

§

impl<'a, T, Request> Send for rustmax::tower::util::Ready<'a, T, Request>
where T: Send,

§

impl<'a, T, S> Send for rustmax::std::collections::hash_set::Entry<'a, T, S>
where T: Send, S: Send,

§

impl<'a, T, S> Send for rustmax::std::collections::hash_set::Difference<'a, T, S>
where S: Sync, T: Sync,

§

impl<'a, T, S> Send for rustmax::std::collections::hash_set::Intersection<'a, T, S>
where S: Sync, T: Sync,

§

impl<'a, T, S> Send for rustmax::std::collections::hash_set::OccupiedEntry<'a, T, S>
where T: Send, S: Send,

§

impl<'a, T, S> Send for rustmax::std::collections::hash_set::SymmetricDifference<'a, T, S>
where S: Sync, T: Sync,

§

impl<'a, T, S> Send for rustmax::std::collections::hash_set::Union<'a, T, S>
where S: Sync, T: Sync,

§

impl<'a, T, S> Send for rustmax::std::collections::hash_set::VacantEntry<'a, T, S>
where T: Send, S: Send,

§

impl<'a, T, const N: usize> !Send for ArrayWindows<'a, T, N>

§

impl<'a, T, const N: usize> Send for rustmax::std::slice::ArrayChunks<'a, T, N>
where T: Sync,

§

impl<'a, T, const N: usize> Send for ArrayChunksMut<'a, T, N>
where T: Send,

§

impl<'a, W> Send for rustmax::futures::io::Close<'a, W>
where W: Send + ?Sized,

§

impl<'a, W> Send for rustmax::futures::io::Flush<'a, W>
where W: Send + ?Sized,

§

impl<'a, W> Send for Write<'a, W>
where W: Send + ?Sized,

§

impl<'a, W> Send for WriteAll<'a, W>
where W: Send + ?Sized,

§

impl<'a, W> Send for WriteVectored<'a, W>
where W: Send + ?Sized,

§

impl<'a, const N: usize> Send for CharArraySearcher<'a, N>

§

impl<'addr, 'bufs, 'control> !Send for MsgHdr<'addr, 'bufs, 'control>

§

impl<'addr, 'bufs, 'control> !Send for MsgHdrMut<'addr, 'bufs, 'control>

§

impl<'b, T> !Send for rustmax::std::cell::Ref<'b, T>

§

impl<'b, T> !Send for RefMut<'b, T>

§

impl<'c, 'a> !Send for StepCursor<'c, 'a>

§

impl<'c, 'h> Send for rustmax::regex::bytes::SubCaptureMatches<'c, 'h>

§

impl<'c, 'h> Send for rustmax::regex::SubCaptureMatches<'c, 'h>

§

impl<'ch> Send for rustmax::rayon::str::Bytes<'ch>

§

impl<'ch> Send for rustmax::rayon::str::CharIndices<'ch>

§

impl<'ch> Send for rustmax::rayon::str::Chars<'ch>

§

impl<'ch> Send for rustmax::rayon::str::EncodeUtf16<'ch>

§

impl<'ch> Send for rustmax::rayon::str::Lines<'ch>

§

impl<'ch> Send for rustmax::rayon::str::SplitAsciiWhitespace<'ch>

§

impl<'ch> Send for rustmax::rayon::str::SplitWhitespace<'ch>

§

impl<'ch, P> Send for rustmax::rayon::str::MatchIndices<'ch, P>

§

impl<'ch, P> Send for rustmax::rayon::str::Matches<'ch, P>

§

impl<'ch, P> Send for rustmax::rayon::str::Split<'ch, P>

§

impl<'ch, P> Send for rustmax::rayon::str::SplitInclusive<'ch, P>

§

impl<'ch, P> Send for rustmax::rayon::str::SplitTerminator<'ch, P>

§

impl<'d> Send for TimeZoneName<'d>

§

impl<'d> Send for TimeZoneNameIter<'d>

§

impl<'d> Send for ValueSerializer<'d>

§

impl<'d> Send for rustmax::toml::Serializer<'d>

§

impl<'data> Send for BorrowedBuf<'data>

§

impl<'data, T> Send for rustmax::rayon::slice::Chunks<'data, T>

§

impl<'data, T> Send for rustmax::rayon::slice::ChunksExact<'data, T>

§

impl<'data, T> Send for rustmax::rayon::slice::ChunksExactMut<'data, T>

§

impl<'data, T> Send for rustmax::rayon::slice::ChunksMut<'data, T>

§

impl<'data, T> Send for rustmax::rayon::slice::Iter<'data, T>

§

impl<'data, T> Send for rustmax::rayon::slice::IterMut<'data, T>

§

impl<'data, T> Send for rustmax::rayon::slice::RChunks<'data, T>

§

impl<'data, T> Send for rustmax::rayon::slice::RChunksExact<'data, T>

§

impl<'data, T> Send for rustmax::rayon::slice::RChunksExactMut<'data, T>

§

impl<'data, T> Send for rustmax::rayon::slice::RChunksMut<'data, T>

§

impl<'data, T> Send for rustmax::rayon::slice::Windows<'data, T>

§

impl<'data, T> Send for rustmax::rayon::vec::Drain<'data, T>

§

impl<'data, T, P> Send for rustmax::rayon::slice::ChunkBy<'data, T, P>
where P: Send, T: Sync,

§

impl<'data, T, P> Send for rustmax::rayon::slice::ChunkByMut<'data, T, P>
where P: Send, T: Send,

§

impl<'data, T, P> Send for rustmax::rayon::slice::Split<'data, T, P>
where P: Send, T: Sync,

§

impl<'data, T, P> Send for rustmax::rayon::slice::SplitInclusive<'data, T, P>
where P: Send, T: Sync,

§

impl<'data, T, P> Send for rustmax::rayon::slice::SplitInclusiveMut<'data, T, P>
where P: Send, T: Send,

§

impl<'data, T, P> Send for rustmax::rayon::slice::SplitMut<'data, T, P>
where P: Send, T: Send,

§

impl<'de> !Send for rustmax::json5::Deserializer<'de>

§

impl<'de, E> Send for BorrowedBytesDeserializer<'de, E>
where E: Send,

§

impl<'de, E> Send for BorrowedStrDeserializer<'de, E>
where E: Send,

§

impl<'de, I, E> Send for MapDeserializer<'de, I, E>
where <<I as Iterator>::Item as Pair>::Second: Send, E: Send, I: Send,

§

impl<'de, R, T> Send for StreamDeserializer<'de, R, T>
where R: Send, T: Send,

§

impl<'e, E, R> Send for DecoderReader<'e, E, R>
where R: Send,

§

impl<'e, E, S> Send for EncoderStringWriter<'e, E, S>
where S: Send,

§

impl<'e, E, W> Send for EncoderWriter<'e, E, W>
where W: Send,

§

impl<'env> Send for rustmax::crossbeam::thread::Scope<'env>

§

impl<'f> !Send for VaListImpl<'f>

§

impl<'f> Send for rustmax::jiff::fmt::strtime::Display<'f>

§

impl<'fd> Send for BorrowedFd<'fd>

§

impl<'fmt, 'a, 'b> !Send for BacktraceFrameFmt<'fmt, 'a, 'b>

§

impl<'g, T> !Send for rustmax::crossbeam::epoch::Shared<'g, T>

§

impl<'g, T, P> !Send for CompareExchangeError<'g, T, P>

§

impl<'h> !Send for rustmax::rustyline::Context<'h>

§

impl<'h> Send for rustmax::regex::bytes::Captures<'h>

§

impl<'h> Send for rustmax::regex::bytes::Match<'h>

§

impl<'h> Send for rustmax::regex::Captures<'h>

§

impl<'h> Send for rustmax::regex::Match<'h>

§

impl<'i> !Send for ValidationContext<'i>

§

impl<'n> Send for TimeZoneAnnotationKind<'n>

§

impl<'n> Send for Pieces<'n>

§

impl<'n> Send for TimeZoneAnnotation<'n>

§

impl<'n> Send for TimeZoneAnnotationName<'n>

§

impl<'r> !Send for EventContext<'r>

§

impl<'r> Send for rustmax::regex::bytes::CaptureNames<'r>

§

impl<'r> Send for rustmax::regex::CaptureNames<'r>

§

impl<'r, 'h> Send for rustmax::regex::bytes::CaptureMatches<'r, 'h>

§

impl<'r, 'h> Send for rustmax::regex::bytes::Matches<'r, 'h>

§

impl<'r, 'h> Send for rustmax::regex::bytes::Split<'r, 'h>

§

impl<'r, 'h> Send for rustmax::regex::bytes::SplitN<'r, 'h>

§

impl<'r, 'h> Send for rustmax::regex::CaptureMatches<'r, 'h>

§

impl<'r, 'h> Send for rustmax::regex::Matches<'r, 'h>

§

impl<'r, 'h> Send for rustmax::regex::Split<'r, 'h>

§

impl<'r, 'h> Send for rustmax::regex::SplitN<'r, 'h>

§

impl<'s> Send for rustmax::regex::bytes::NoExpand<'s>

§

impl<'s> Send for rustmax::regex::NoExpand<'s>

§

impl<'s> Send for SockRef<'s>

§

impl<'scope> Send for rustmax::rayon::Scope<'scope>

§

impl<'scope> Send for ScopeFifo<'scope>

§

impl<'scope, 'env> Send for ScopedThreadBuilder<'scope, 'env>

§

impl<'scope, 'env> Send for rustmax::std::thread::Scope<'scope, 'env>

§

impl<'scope, T> Send for rustmax::std::thread::ScopedJoinHandle<'scope, T>
where T: Send,

§

impl<'t> Send for TimeZoneFollowingTransitions<'t>

§

impl<'t> Send for TimeZoneOffsetInfo<'t>

§

impl<'t> Send for TimeZonePrecedingTransitions<'t>

§

impl<'t> Send for TimeZoneTransition<'t>

§

impl<A> Send for IterRange<A>
where A: Send,

§

impl<A> Send for IterRangeFrom<A>
where A: Send,

§

impl<A> Send for IterRangeInclusive<A>
where A: Send,

§

impl<A> Send for rustmax::itertools::RepeatN<A>
where A: Send,

§

impl<A> Send for EnumAccessDeserializer<A>
where A: Send,

§

impl<A> Send for MapAccessDeserializer<A>
where A: Send,

§

impl<A> Send for SeqAccessDeserializer<A>
where A: Send,

§

impl<A> Send for rustmax::std::iter::Repeat<A>
where A: Send,

§

impl<A> Send for rustmax::std::iter::RepeatN<A>
where A: Send,

§

impl<A> Send for rustmax::std::option::IntoIter<A>
where A: Send,

§

impl<A, B> Send for rustmax::futures::prelude::future::Either<A, B>
where A: Send, B: Send,

§

impl<A, B> Send for EitherOrBoth<A, B>
where A: Send, B: Send,

§

impl<A, B> Send for rustmax::tower::util::Either<A, B>
where A: Send, B: Send,

§

impl<A, B> Send for rustmax::futures::prelude::future::Select<A, B>
where A: Send, B: Send,

§

impl<A, B> Send for TrySelect<A, B>
where A: Send, B: Send,

§

impl<A, B> Send for rustmax::rayon::iter::Chain<A, B>

§

impl<A, B> Send for rustmax::rayon::iter::Zip<A, B>

§

impl<A, B> Send for rustmax::rayon::iter::ZipEq<A, B>

§

impl<A, B> Send for EitherResponseFuture<A, B>
where A: Send, B: Send,

§

impl<A, B> Send for rustmax::std::iter::Chain<A, B>
where A: Send, B: Send,

§

impl<A, B> Send for rustmax::std::iter::Zip<A, B>
where A: Send, B: Send,

§

impl<B> Send for rustmax::bitflags::iter::Iter<B>
where B: Send + Sync,

§

impl<B> Send for IterNames<B>
where B: Send + Sync,

§

impl<B> Send for Flag<B>
where B: Send,

§

impl<B> Send for Reader<B>
where B: Send,

§

impl<B> Send for Writer<B>
where B: Send,

§

impl<B> Send for rustmax::hyper::client::conn::http1::SendRequest<B>
where B: Send,

§

impl<B> Send for rustmax::hyper::client::conn::http2::SendRequest<B>
where B: Send,

§

impl<B> Send for rustmax::std::io::Lines<B>
where B: Send,

§

impl<B> Send for rustmax::std::io::Split<B>
where B: Send,

§

impl<B, C> Send for ControlFlow<B, C>
where C: Send, B: Send,

§

impl<B, S> Send for RouterIntoService<B, S>
where B: Send,

§

impl<B, T, E, S> Send for rustmax::axum::middleware::future::FromExtractorResponseFuture<B, T, E, S>
where <T as Service<Request<B>>>::Future: Send, T: Send,

§

impl<BlockSize, Kind> Send for BlockBuffer<BlockSize, Kind>
where Kind: Send,

§

impl<D, C> Send for PeakEwmaDiscover<D, C>
where D: Send, C: Send,

§

impl<D, C> Send for PendingRequestsDiscover<D, C>
where D: Send, C: Send,

§

impl<D, F, T, S> Send for rustmax::rand::distr::Map<D, F, T, S>
where D: Send, F: Send,

§

impl<D, R, T> Send for rustmax::rand::distr::Iter<D, R, T>
where D: Send, R: Send, T: Send,

§

impl<D, Req> Send for Balance<D, Req>
where D: Send, Req: Send, <D as Discover>::Key: Send, <D as Discover>::Service: Send,

§

impl<D, Req> Send for MakeBalanceLayer<D, Req>

§

impl<D, S> Send for rustmax::rayon::iter::Split<D, S>
where D: Send, S: Send,

§

impl<E> Send for RouteFuture<E>

§

impl<E> Send for Route<E>

§

impl<E> Send for EnumValueParser<E>

§

impl<E> Send for rustmax::hyper::server::conn::http2::Builder<E>
where E: Send,

§

impl<E> Send for rustmax::nom::bytes::Take<E>
where E: Send,

§

impl<E> Send for AnyChar<E>
where E: Send,

§

impl<E> Send for Char<E>
where E: Send,

§

impl<E> Send for Digit1<E>
where E: Send,

§

impl<E> Send for MultiSpace0<E>
where E: Send,

§

impl<E> Send for BoolDeserializer<E>
where E: Send,

§

impl<E> Send for CharDeserializer<E>
where E: Send,

§

impl<E> Send for F32Deserializer<E>
where E: Send,

§

impl<E> Send for F64Deserializer<E>
where E: Send,

§

impl<E> Send for I8Deserializer<E>
where E: Send,

§

impl<E> Send for I16Deserializer<E>
where E: Send,

§

impl<E> Send for I32Deserializer<E>
where E: Send,

§

impl<E> Send for I64Deserializer<E>
where E: Send,

§

impl<E> Send for I128Deserializer<E>
where E: Send,

§

impl<E> Send for IsizeDeserializer<E>
where E: Send,

§

impl<E> Send for StringDeserializer<E>
where E: Send,

§

impl<E> Send for U8Deserializer<E>
where E: Send,

§

impl<E> Send for U16Deserializer<E>
where E: Send,

§

impl<E> Send for U32Deserializer<E>
where E: Send,

§

impl<E> Send for U64Deserializer<E>
where E: Send,

§

impl<E> Send for U128Deserializer<E>
where E: Send,

§

impl<E> Send for UnitDeserializer<E>
where E: Send,

§

impl<E> Send for UsizeDeserializer<E>
where E: Send,

§

impl<E> Send for Report<E>
where E: Send,

§

impl<E, M> Send for Capture<E, M>
where E: Send, M: Send,

§

impl<E, S> Send for FromExtractorLayer<E, S>
where S: Send,

§

impl<Enum> Send for TryFromPrimitiveError<Enum>
where <Enum as TryFromPrimitive>::Primitive: Send,

§

impl<Ex> Send for rustmax::hyper::client::conn::http2::Builder<Ex>
where Ex: Send,

§

impl<F1, F2, N> Send for AndThenFuture<F1, F2, N>
where F2: Send, N: Send, F1: Send,

§

impl<F1, F2, N> Send for ThenFuture<F1, F2, N>
where F2: Send, F1: Send, N: Send,

§

impl<F> Send for IntoServiceFuture<F>
where F: Send,

§

impl<F> Send for rustmax::clap::error::Error<F>
where F: Send,

§

impl<F> Send for rustmax::futures::prelude::future::Flatten<F>
where F: Send, <F as Future>::Output: Send,

§

impl<F> Send for FlattenStream<F>
where F: Send, <F as Future>::Output: Send,

§

impl<F> Send for rustmax::futures::prelude::future::IntoStream<F>
where F: Send,

§

impl<F> Send for JoinAll<F>
where F: Send, <F as Future>::Output: Send,

§

impl<F> Send for rustmax::futures::prelude::future::Lazy<F>
where F: Send,

§

impl<F> Send for OptionFuture<F>
where F: Send,

§

impl<F> Send for rustmax::futures::prelude::future::PollFn<F>
where F: Send,

§

impl<F> Send for TryJoinAll<F>
where <F as TryFuture>::Ok: Send, F: Send, <F as TryFuture>::Error: Send,

§

impl<F> Send for rustmax::futures::prelude::stream::PollFn<F>
where F: Send,

§

impl<F> Send for rustmax::futures::prelude::stream::RepeatWith<F>
where F: Send,

§

impl<F> Send for AllConsuming<F>
where F: Send,

§

impl<F> Send for Cond<F>
where F: Send,

§

impl<F> Send for Consumed<F>
where F: Send,

§

impl<F> Send for Cut<F>
where F: Send,

§

impl<F> Send for MakeComplete<F>
where F: Send,

§

impl<F> Send for rustmax::nom::combinator::Not<F>
where F: Send,

§

impl<F> Send for Opt<F>
where F: Send,

§

impl<F> Send for rustmax::nom::combinator::Peek<F>
where F: Send,

§

impl<F> Send for Recognize<F>
where F: Send,

§

impl<F> Send for rustmax::nom::error::Context<F>
where F: Send,

§

impl<F> Send for rustmax::nom::multi::Count<F>
where F: Send,

§

impl<F> Send for Many0<F>
where F: Send,

§

impl<F> Send for Many0Count<F>
where F: Send,

§

impl<F> Send for Many1<F>
where F: Send,

§

impl<F> Send for Many1Count<F>
where F: Send,

§

impl<F> Send for ManyMN<F>
where F: Send,

§

impl<F> Send for NamedTempFile<F>
where F: Send,

§

impl<F> Send for PersistError<F>
where F: Send,

§

impl<F> Send for Unconstrained<F>
where F: Send,

§

impl<F> Send for LayerFn<F>
where F: Send,

§

impl<F> Send for rustmax::tower::load_shed::future::ResponseFuture<F>
where F: Send,

§

impl<F> Send for AndThenLayer<F>
where F: Send,

§

impl<F> Send for MapErrLayer<F>
where F: Send,

§

impl<F> Send for MapFutureLayer<F>
where F: Send,

§

impl<F> Send for rustmax::tower::util::MapRequestLayer<F>
where F: Send,

§

impl<F> Send for rustmax::tower::util::MapResponseLayer<F>
where F: Send,

§

impl<F> Send for MapResultLayer<F>
where F: Send,

§

impl<F> Send for ThenLayer<F>
where F: Send,

§

impl<F> Send for rustmax::std::fmt::FromFn<F>
where F: Send,

§

impl<F> Send for rustmax::std::future::PollFn<F>
where F: Send,

§

impl<F> Send for rustmax::std::iter::FromFn<F>
where F: Send,

§

impl<F> Send for OnceWith<F>
where F: Send,

§

impl<F> Send for rustmax::std::iter::RepeatWith<F>
where F: Send,

§

impl<F, C, H> Send for TrackCompletionFuture<F, C, H>
where F: Send, C: Send, H: Send,

§

impl<F, E> Send for SplitPosition1<F, E>
where F: Send, E: Send,

§

impl<F, E> Send for SplitPosition<F, E>
where F: Send, E: Send,

§

impl<F, E> Send for TakeWhileMN<F, E>
where F: Send, E: Send,

§

impl<F, E> Send for rustmax::tower::reconnect::ResponseFuture<F, E>
where F: Send, E: Send,

§

impl<F, E> Send for rustmax::tower::spawn_ready::future::ResponseFuture<F, E>
where F: Send,

§

impl<F, G> Send for SeparatedList0<F, G>
where F: Send, G: Send,

§

impl<F, G> Send for SeparatedList1<F, G>
where F: Send, G: Send,

§

impl<F, G> Send for Preceded<F, G>
where F: Send, G: Send,

§

impl<F, G> Send for Terminated<F, G>
where F: Send, G: Send,

§

impl<F, G> Send for rustmax::nom::And<F, G>
where F: Send, G: Send,

§

impl<F, G> Send for rustmax::nom::AndThen<F, G>
where F: Send, G: Send,

§

impl<F, G> Send for rustmax::nom::FlatMap<F, G>
where F: Send, G: Send,

§

impl<F, G> Send for rustmax::nom::Map<F, G>
where F: Send, G: Send,

§

impl<F, G> Send for MapOpt<F, G>
where F: Send, G: Send,

§

impl<F, G> Send for MapRes<F, G>
where F: Send, G: Send,

§

impl<F, G> Send for rustmax::nom::Or<F, G>
where F: Send, G: Send,

§

impl<F, G, E> Send for Escaped<F, G, E>
where F: Send, G: Send, E: Send,

§

impl<F, G, E> Send for LengthCount<F, G, E>
where F: Send, G: Send, E: Send,

§

impl<F, G, E> Send for LengthValue<F, G, E>
where F: Send, G: Send, E: Send,

§

impl<F, G, E> Send for ManyTill<F, G, E>
where F: Send, G: Send, E: Send,

§

impl<F, G, E, ExtendItem, Output> Send for EscapedTransform<F, G, E, ExtendItem, Output>
where F: Send, G: Send, E: Send, ExtendItem: Send, Output: Send,

§

impl<F, G, H, Range> Send for rustmax::nom::multi::Fold<F, G, H, Range>
where F: Send, H: Send, G: Send, Range: Send,

§

impl<F, G, Init, R> Send for FoldMany0<F, G, Init, R>
where F: Send, G: Send, Init: Send, R: Send,

§

impl<F, G, Init, R> Send for FoldMany1<F, G, Init, R>
where F: Send, G: Send, Init: Send, R: Send,

§

impl<F, G, Init, R> Send for FoldManyMN<F, G, Init, R>
where F: Send, G: Send, Init: Send, R: Send,

§

impl<F, G, O2> Send for Verify<F, G, O2>
where F: Send, G: Send, O2: Send + ?Sized,

§

impl<F, MakeError> Send for Satisfy<F, MakeError>
where F: Send, MakeError: Send,

§

impl<F, N> Send for MapErrFuture<F, N>
where F: Send, N: Send,

§

impl<F, N> Send for MapResponseFuture<F, N>
where F: Send, N: Send,

§

impl<F, N> Send for MapResultFuture<F, N>
where F: Send, N: Send,

§

impl<F, O2, E2> Send for Into<F, O2, E2>
where F: Send, O2: Send, E2: Send,

§

impl<F, R, Collection> Send for Many<F, R, Collection>
where F: Send, R: Send, Collection: Send,

§

impl<F, Req> Send for MakeFuture<F, Req>
where F: Send,

§

impl<F, S> Send for FutureService<F, S>
where F: Send, S: Send,

§

impl<F, S, I, T> Send for rustmax::axum::middleware::FromFn<F, S, I, T>
where F: Send, I: Send, S: Send,

§

impl<F, S, I, T> Send for rustmax::axum::middleware::MapRequest<F, S, I, T>
where F: Send, I: Send, S: Send,

§

impl<F, S, I, T> Send for rustmax::axum::middleware::MapResponse<F, S, I, T>
where F: Send, I: Send, S: Send,

§

impl<F, S, T> Send for FromFnLayer<F, S, T>
where F: Send, S: Send,

§

impl<F, S, T> Send for rustmax::axum::middleware::MapRequestLayer<F, S, T>
where F: Send, S: Send,

§

impl<F, S, T> Send for rustmax::axum::middleware::MapResponseLayer<F, S, T>
where F: Send, S: Send,

§

impl<F, T> Send for HandleErrorLayer<F, T>
where F: Send,

§

impl<Failure, Error> Send for Err<Failure, Error>
where Error: Send, Failure: Send,

§

impl<Fut1, Fut2> Send for rustmax::futures::prelude::future::Join<Fut1, Fut2>
where Fut1: Send, <Fut1 as Future>::Output: Send, Fut2: Send, <Fut2 as Future>::Output: Send,

§

impl<Fut1, Fut2> Send for rustmax::futures::prelude::future::TryFlatten<Fut1, Fut2>
where Fut1: Send, Fut2: Send,

§

impl<Fut1, Fut2> Send for TryJoin<Fut1, Fut2>
where Fut1: Send, <Fut1 as TryFuture>::Ok: Send, Fut2: Send, <Fut2 as TryFuture>::Ok: Send,

§

impl<Fut1, Fut2, F> Send for rustmax::futures::prelude::future::AndThen<Fut1, Fut2, F>
where Fut2: Send, Fut1: Send, F: Send,

§

impl<Fut1, Fut2, F> Send for rustmax::futures::prelude::future::OrElse<Fut1, Fut2, F>
where Fut2: Send, Fut1: Send, F: Send,

§

impl<Fut1, Fut2, F> Send for rustmax::futures::prelude::future::Then<Fut1, Fut2, F>
where Fut2: Send, Fut1: Send, F: Send,

§

impl<Fut1, Fut2, Fut3> Send for Join3<Fut1, Fut2, Fut3>
where Fut1: Send, <Fut1 as Future>::Output: Send, Fut2: Send, <Fut2 as Future>::Output: Send, Fut3: Send, <Fut3 as Future>::Output: Send,

§

impl<Fut1, Fut2, Fut3> Send for TryJoin3<Fut1, Fut2, Fut3>
where Fut1: Send, <Fut1 as TryFuture>::Ok: Send, Fut2: Send, <Fut2 as TryFuture>::Ok: Send, Fut3: Send, <Fut3 as TryFuture>::Ok: Send,

§

impl<Fut1, Fut2, Fut3, Fut4> Send for Join4<Fut1, Fut2, Fut3, Fut4>
where Fut1: Send, <Fut1 as Future>::Output: Send, Fut2: Send, <Fut2 as Future>::Output: Send, Fut3: Send, <Fut3 as Future>::Output: Send, Fut4: Send, <Fut4 as Future>::Output: Send,

§

impl<Fut1, Fut2, Fut3, Fut4> Send for TryJoin4<Fut1, Fut2, Fut3, Fut4>
where Fut1: Send, <Fut1 as TryFuture>::Ok: Send, Fut2: Send, <Fut2 as TryFuture>::Ok: Send, Fut3: Send, <Fut3 as TryFuture>::Ok: Send, Fut4: Send, <Fut4 as TryFuture>::Ok: Send,

§

impl<Fut1, Fut2, Fut3, Fut4, Fut5> Send for Join5<Fut1, Fut2, Fut3, Fut4, Fut5>
where Fut1: Send, <Fut1 as Future>::Output: Send, Fut2: Send, <Fut2 as Future>::Output: Send, Fut3: Send, <Fut3 as Future>::Output: Send, Fut4: Send, <Fut4 as Future>::Output: Send, Fut5: Send, <Fut5 as Future>::Output: Send,

§

impl<Fut1, Fut2, Fut3, Fut4, Fut5> Send for TryJoin5<Fut1, Fut2, Fut3, Fut4, Fut5>
where Fut1: Send, <Fut1 as TryFuture>::Ok: Send, Fut2: Send, <Fut2 as TryFuture>::Ok: Send, Fut3: Send, <Fut3 as TryFuture>::Ok: Send, Fut4: Send, <Fut4 as TryFuture>::Ok: Send, Fut5: Send, <Fut5 as TryFuture>::Ok: Send,

§

impl<Fut> Send for MaybeDone<Fut>
where Fut: Send, <Fut as Future>::Output: Send,

§

impl<Fut> Send for TryMaybeDone<Fut>
where Fut: Send, <Fut as TryFuture>::Ok: Send,

§

impl<Fut> Send for rustmax::futures::prelude::future::CatchUnwind<Fut>
where Fut: Send,

§

impl<Fut> Send for rustmax::futures::prelude::future::Fuse<Fut>
where Fut: Send,

§

impl<Fut> Send for IntoFuture<Fut>
where Fut: Send,

§

impl<Fut> Send for NeverError<Fut>
where Fut: Send,

§

impl<Fut> Send for Remote<Fut>
where Fut: Send, <Fut as Future>::Output: Send,

§

impl<Fut> Send for rustmax::futures::prelude::future::SelectAll<Fut>
where Fut: Send,

§

impl<Fut> Send for SelectOk<Fut>
where Fut: Send,

§

impl<Fut> Send for rustmax::futures::prelude::future::Shared<Fut>
where Fut: Send, <Fut as Future>::Output: Send + Sync,

§

impl<Fut> Send for TryFlattenStream<Fut>
where Fut: Send, <Fut as TryFuture>::Ok: Send,

§

impl<Fut> Send for rustmax::futures::prelude::future::UnitError<Fut>
where Fut: Send,

§

impl<Fut> Send for WeakShared<Fut>
where Fut: Send, <Fut as Future>::Output: Send + Sync,

§

impl<Fut> Send for rustmax::futures::prelude::stream::Once<Fut>
where Fut: Send,

§

impl<Fut, E> Send for rustmax::futures::prelude::future::ErrInto<Fut, E>
where Fut: Send,

§

impl<Fut, E> Send for OkInto<Fut, E>
where Fut: Send,

§

impl<Fut, F> Send for rustmax::futures::prelude::future::Inspect<Fut, F>
where Fut: Send, F: Send,

§

impl<Fut, F> Send for rustmax::futures::prelude::future::InspectErr<Fut, F>
where Fut: Send, F: Send,

§

impl<Fut, F> Send for rustmax::futures::prelude::future::InspectOk<Fut, F>
where Fut: Send, F: Send,

§

impl<Fut, F> Send for rustmax::futures::prelude::future::Map<Fut, F>
where Fut: Send, F: Send,

§

impl<Fut, F> Send for rustmax::futures::prelude::future::MapErr<Fut, F>
where Fut: Send, F: Send,

§

impl<Fut, F> Send for rustmax::futures::prelude::future::MapOk<Fut, F>
where Fut: Send, F: Send,

§

impl<Fut, F> Send for UnwrapOrElse<Fut, F>
where Fut: Send, F: Send,

§

impl<Fut, F, G> Send for MapOkOrElse<Fut, F, G>
where Fut: Send, F: Send, G: Send,

§

impl<Fut, Si> Send for FlattenSink<Fut, Si>
where Fut: Send, Si: Send,

§

impl<Fut, T> Send for rustmax::futures::prelude::future::MapInto<Fut, T>
where Fut: Send,

§

impl<H> Send for HasherRng<H>
where H: Send,

§

impl<H> Send for BuildHasherDefault<H>

§

impl<H, I> Send for Editor<H, I>
where I: Send, H: Send,

§

impl<H, T, S> Send for HandlerService<H, T, S>
where H: Send, S: Send,

§

impl<I> !Send for RcIter<I>

§

impl<I> !Send for Tee<I>

§

impl<I> Send for AppendHeaders<I>
where I: Send,

§

impl<I> Send for DelayedFormat<I>
where I: Send,

§

impl<I> Send for rustmax::futures::prelude::stream::Iter<I>
where I: Send,

§

impl<I> Send for CombinationsWithReplacement<I>
where <I as Iterator>::Item: Sized + Send, I: Send,

§

impl<I> Send for ExactlyOneError<I>
where I: Send, <I as Iterator>::Item: Send,

§

impl<I> Send for GroupingMap<I>
where I: Send,

§

impl<I> Send for IntoChunks<I>
where I: Send, <I as Iterator>::Item: Send,

§

impl<I> Send for MultiPeek<I>
where I: Send, <I as Iterator>::Item: Send,

§

impl<I> Send for MultiProduct<I>
where <I as Iterator>::Item: Sized + Send, I: Send,

§

impl<I> Send for PeekNth<I>
where I: Send, <I as Iterator>::Item: Send,

§

impl<I> Send for Permutations<I>
where I: Send, <I as Iterator>::Item: Send,

§

impl<I> Send for Powerset<I>
where I: Send, <I as Iterator>::Item: Send,

§

impl<I> Send for PutBack<I>
where I: Send, <I as Iterator>::Item: Send,

§

impl<I> Send for PutBackN<I>
where I: Send, <I as Iterator>::Item: Send,

§

impl<I> Send for Unique<I>
where <I as Iterator>::Item: Sized + Send, I: Send,

§

impl<I> Send for rustmax::itertools::WhileSome<I>
where I: Send,

§

impl<I> Send for WithPosition<I>
where I: Send, <I as Iterator>::Item: Send,

§

impl<I> Send for rustmax::nom::error::Error<I>
where I: Send,

§

impl<I> Send for rustmax::rayon::iter::Chunks<I>

§

impl<I> Send for rustmax::rayon::iter::Cloned<I>

§

impl<I> Send for rustmax::rayon::iter::Copied<I>

§

impl<I> Send for rustmax::rayon::iter::Enumerate<I>

§

impl<I> Send for ExponentialBlocks<I>
where I: Send,

§

impl<I> Send for rustmax::rayon::iter::Flatten<I>

§

impl<I> Send for FlattenIter<I>

§

impl<I> Send for rustmax::rayon::iter::Intersperse<I>
where <I as ParallelIterator>::Item: Sized,

§

impl<I> Send for MaxLen<I>

§

impl<I> Send for MinLen<I>

§

impl<I> Send for PanicFuse<I>

§

impl<I> Send for rustmax::rayon::iter::Rev<I>

§

impl<I> Send for rustmax::rayon::iter::Skip<I>
where I: Send,

§

impl<I> Send for SkipAny<I>

§

impl<I> Send for rustmax::rayon::iter::StepBy<I>

§

impl<I> Send for rustmax::rayon::iter::Take<I>
where I: Send,

§

impl<I> Send for TakeAny<I>

§

impl<I> Send for UniformBlocks<I>
where I: Send,

§

impl<I> Send for rustmax::rayon::iter::WhileSome<I>

§

impl<I> Send for FromIter<I>
where I: Send,

§

impl<I> Send for DecodeUtf16<I>
where I: Send,

§

impl<I> Send for rustmax::std::iter::Cloned<I>
where I: Send,

§

impl<I> Send for rustmax::std::iter::Copied<I>
where I: Send,

§

impl<I> Send for rustmax::std::iter::Cycle<I>
where I: Send,

§

impl<I> Send for rustmax::std::iter::Enumerate<I>
where I: Send,

§

impl<I> Send for rustmax::std::iter::Flatten<I>
where <<I as Iterator>::Item as IntoIterator>::IntoIter: Send, I: Send,

§

impl<I> Send for rustmax::std::iter::Fuse<I>
where I: Send,

§

impl<I> Send for rustmax::std::iter::Intersperse<I>
where <I as Iterator>::Item: Sized + Send, I: Send,

§

impl<I> Send for rustmax::std::iter::Peekable<I>
where I: Send, <I as Iterator>::Item: Send,

§

impl<I> Send for rustmax::std::iter::Skip<I>
where I: Send,

§

impl<I> Send for rustmax::std::iter::StepBy<I>
where I: Send,

§

impl<I> Send for rustmax::std::iter::Take<I>
where I: Send,

§

impl<I, E> Send for SeqDeserializer<I, E>
where E: Send, I: Send,

§

impl<I, E, F> Send for ParserIterator<I, E, F>
where F: Send, I: Send, E: Send,

§

impl<I, ElemF> Send for rustmax::itertools::IntersperseWith<I, ElemF>
where ElemF: Send, I: Send, <I as Iterator>::Item: Send,

§

impl<I, F> Send for Batching<I, F>
where F: Send, I: Send,

§

impl<I, F> Send for FilterMapOk<I, F>
where I: Send, F: Send,

§

impl<I, F> Send for FilterOk<I, F>
where I: Send, F: Send,

§

impl<I, F> Send for KMergeBy<I, F>
where F: Send, <I as Iterator>::Item: Send, I: Send,

§

impl<I, F> Send for PadUsing<I, F>
where F: Send, I: Send,

§

impl<I, F> Send for rustmax::itertools::Positions<I, F>
where F: Send, I: Send,

§

impl<I, F> Send for TakeWhileInclusive<I, F>
where I: Send, F: Send,

§

impl<I, F> Send for rustmax::itertools::Update<I, F>
where I: Send, F: Send,

§

impl<I, F> Send for rustmax::rayon::iter::FlatMap<I, F>
where F: Send,

§

impl<I, F> Send for FlatMapIter<I, F>
where F: Send,

§

impl<I, F> Send for rustmax::rayon::iter::Inspect<I, F>
where F: Send,

§

impl<I, F> Send for rustmax::rayon::iter::Map<I, F>
where F: Send,

§

impl<I, F> Send for rustmax::rayon::iter::Update<I, F>
where F: Send,

§

impl<I, F> Send for rustmax::std::iter::FilterMap<I, F>
where I: Send, F: Send,

§

impl<I, F> Send for rustmax::std::iter::Inspect<I, F>
where I: Send, F: Send,

§

impl<I, F> Send for rustmax::std::iter::Map<I, F>
where I: Send, F: Send,

§

impl<I, F, const N: usize> Send for MapWindows<I, F, N>
where F: Send, I: Send, <I as Iterator>::Item: Send,

§

impl<I, G> Send for rustmax::std::iter::IntersperseWith<I, G>
where G: Send, <I as Iterator>::Item: Send, I: Send,

§

impl<I, ID, F> Send for rustmax::rayon::iter::Fold<I, ID, F>
where I: Send, ID: Send, F: Send,

§

impl<I, ID, F> Send for FoldChunks<I, ID, F>
where F: Send, ID: Send,

§

impl<I, INIT, F> Send for MapInit<I, INIT, F>
where INIT: Send, F: Send,

§

impl<I, J> Send for Diff<I, J>
where I: Send, J: Send, <I as Iterator>::Item: Send, <J as Iterator>::Item: Send,

§

impl<I, J> Send for rustmax::itertools::Interleave<I, J>
where I: Send, J: Send,

§

impl<I, J> Send for rustmax::itertools::InterleaveShortest<I, J>
where I: Send, J: Send,

§

impl<I, J> Send for Product<I, J>
where I: Send, J: Send, <I as Iterator>::Item: Send,

§

impl<I, J> Send for rustmax::itertools::ZipEq<I, J>
where I: Send, J: Send,

§

impl<I, J> Send for rustmax::rayon::iter::Interleave<I, J>

§

impl<I, J> Send for rustmax::rayon::iter::InterleaveShortest<I, J>

§

impl<I, J, F> Send for MergeBy<I, J, F>
where F: Send, <I as Iterator>::Item: Send, <J as Iterator>::Item: Send, I: Send, J: Send,

§

impl<I, O> Send for Client<I, O>

§

impl<I, P> Send for rustmax::rayon::iter::Filter<I, P>
where P: Send,

§

impl<I, P> Send for rustmax::rayon::iter::FilterMap<I, P>
where P: Send,

§

impl<I, P> Send for rustmax::rayon::iter::Positions<I, P>
where P: Send,

§

impl<I, P> Send for SkipAnyWhile<I, P>
where P: Send,

§

impl<I, P> Send for TakeAnyWhile<I, P>
where P: Send,

§

impl<I, P> Send for FilterEntry<I, P>
where I: Send, P: Send,

§

impl<I, P> Send for rustmax::std::iter::Filter<I, P>
where I: Send, P: Send,

§

impl<I, P> Send for MapWhile<I, P>
where I: Send, P: Send,

§

impl<I, P> Send for rustmax::std::iter::SkipWhile<I, P>
where I: Send, P: Send,

§

impl<I, P> Send for rustmax::std::iter::TakeWhile<I, P>
where I: Send, P: Send,

§

impl<I, St, F> Send for rustmax::std::iter::Scan<I, St, F>
where I: Send, F: Send, St: Send,

§

impl<I, T> Send for CircularTupleWindows<I, T>
where I: Send, T: Send,

§

impl<I, T> Send for TupleCombinations<I, T>
where <T as HasCombination<I>>::Combination: Send, I: Send,

§

impl<I, T> Send for TupleWindows<I, T>
where I: Send, T: Send,

§

impl<I, T> Send for Tuples<I, T>
where <T as TupleCollect>::Buffer: Send, I: Send,

§

impl<I, T, E> Send for FlattenOk<I, T, E>
where I: Send, <T as IntoIterator>::IntoIter: Send,

§

impl<I, T, F> Send for MapWith<I, T, F>
where T: Send, F: Send,

§

impl<I, U, F> Send for FoldChunksWith<I, U, F>
where U: Send, F: Send,

§

impl<I, U, F> Send for FoldWith<I, U, F>
where I: Send, U: Send, F: Send,

§

impl<I, U, F> Send for TryFoldWith<I, U, F>
where I: Send, <U as Try>::Output: Send, F: Send,

§

impl<I, U, F> Send for rustmax::std::iter::FlatMap<I, U, F>
where <U as IntoIterator>::IntoIter: Send, I: Send, F: Send,

§

impl<I, U, ID, F> Send for rustmax::rayon::iter::TryFold<I, U, ID, F>
where I: Send, ID: Send, F: Send, U: Send,

§

impl<I, V, F> Send for UniqueBy<I, V, F>
where I: Send, F: Send, V: Send,

§

impl<I, const N: usize> Send for rustmax::std::iter::ArrayChunks<I, N>
where I: Send, <I as Iterator>::Item: Send,

§

impl<IU, B> Send for InvertedUInt<IU, B>
where IU: Send, B: Send,

§

impl<Idx> Send for rustmax::core::range::Range<Idx>
where Idx: Send,

§

impl<Idx> Send for rustmax::core::range::RangeFrom<Idx>
where Idx: Send,

§

impl<Idx> Send for rustmax::core::range::RangeInclusive<Idx>
where Idx: Send,

§

impl<Idx> Send for rustmax::std::ops::Range<Idx>
where Idx: Send,

§

impl<Idx> Send for rustmax::std::ops::RangeFrom<Idx>
where Idx: Send,

§

impl<Idx> Send for rustmax::std::ops::RangeInclusive<Idx>
where Idx: Send,

§

impl<Idx> Send for RangeTo<Idx>
where Idx: Send,

§

impl<Idx> Send for RangeToInclusive<Idx>
where Idx: Send,

§

impl<In, T, U, E> Send for BoxCloneServiceLayer<In, T, U, E>

§

impl<In, T, U, E> Send for BoxCloneSyncServiceLayer<In, T, U, E>

§

impl<In, T, U, E> Send for BoxLayer<In, T, U, E>

§

impl<Inner, Outer> Send for rustmax::tower::layer::util::Stack<Inner, Outer>
where Inner: Send, Outer: Send,

§

impl<Iter> Send for IterBridge<Iter>
where Iter: Send,

§

impl<K> Send for Failed<K>
where K: Send,

§

impl<K> Send for rustmax::std::collections::hash_set::IntoIter<K>
where K: Send,

§

impl<K, I, F> Send for rustmax::itertools::ChunkBy<K, I, F>
where F: Send, I: Send, K: Send, <I as Iterator>::Item: Send,

§

impl<K, S, Req> Send for ReadyCache<K, S, Req>
where K: Send, S: Send, Req: Send,

§

impl<K, V> Send for Change<K, V>
where K: Send, V: Send,

§

impl<K, V> Send for BTreeMapStrategy<K, V>
where K: Send, V: Send,

§

impl<K, V> Send for BTreeMapValueTree<K, V>
where K: Send, V: Send,

§

impl<K, V> Send for HashMapStrategy<K, V>
where K: Send, V: Send,

§

impl<K, V> Send for HashMapValueTree<K, V>
where K: Send, V: Send,

§

impl<K, V> Send for rustmax::rayon::collections::btree_map::IntoIter<K, V>

§

impl<K, V> Send for rustmax::rayon::collections::hash_map::IntoIter<K, V>

§

impl<K, V> Send for rustmax::tera::Map<K, V>
where K: Send, V: Send,

§

impl<K, V> Send for rustmax::toml::map::Map<K, V>
where K: Send, V: Send,

§

impl<K, V> Send for rustmax::std::collections::hash_map::IntoIter<K, V>
where K: Send, V: Send,

§

impl<K, V> Send for rustmax::std::collections::hash_map::IntoKeys<K, V>
where K: Send, V: Send,

§

impl<K, V> Send for rustmax::std::collections::hash_map::IntoValues<K, V>
where K: Send, V: Send,

§

impl<K, V, A> Send for BTreeMap<K, V, A>
where A: Send, K: Send, V: Send,

§

impl<K, V, A> Send for rustmax::std::collections::btree_map::IntoIter<K, V, A>
where A: Send, K: Send, V: Send,

§

impl<K, V, A> Send for rustmax::std::collections::btree_map::IntoKeys<K, V, A>
where A: Send, K: Send, V: Send,

§

impl<K, V, A> Send for rustmax::std::collections::btree_map::IntoValues<K, V, A>
where A: Send, K: Send, V: Send,

§

impl<K, V, S> Send for AHashMap<K, V, S>
where S: Send, K: Send, V: Send,

§

impl<K, V, S> Send for HashMap<K, V, S>
where S: Send, K: Send, V: Send,

§

impl<L> Send for ServiceBuilder<L>
where L: Send,

§

impl<L, F> Send for TapIo<L, F>
where L: Send, F: Send,

§

impl<L, H, T, S> Send for Layered<L, H, T, S>
where L: Send, H: Send,

§

impl<L, M, S> Send for Serve<L, M, S>
where L: Send, M: Send, S: Send,

§

impl<L, M, S, F> Send for WithGracefulShutdown<L, M, S, F>
where L: Send, M: Send, F: Send, S: Send,

§

impl<L, R> Send for rustmax::rayon::iter::Either<L, R>
where L: Send, R: Send,

§

impl<M, EM, S> Send for OutputM<M, EM, S>
where M: Send, EM: Send, S: Send,

§

impl<M, Request> Send for IntoService<M, Request>
where M: Send, Request: Send,

§

impl<M, Target> Send for Reconnect<M, Target>
where M: Send, Target: Send, <M as Service<Target>>::Future: Send, <M as Service<Target>>::Response: Send, <M as Service<Target>>::Error: Send,

§

impl<O, E> Send for Fail<O, E>
where O: Send, E: Send,

§

impl<O, E> Send for Success<O, E>
where O: Send, E: Send,

§

impl<Ok, Error> Send for Impossible<Ok, Error>
where Ok: Send, Error: Send,

§

impl<P> Send for RetryLayer<P>
where P: Send,

§

impl<P> Send for CrossThread<P>
where P: Send,

§

impl<P> Send for MaybeCrossThread<P>
where P: Send,

§

impl<P, F> Send for MapValueParser<P, F>
where P: Send, F: Send,

§

impl<P, F> Send for TryMapValueParser<P, F>
where P: Send, F: Send,

§

impl<P, S> Send for Retry<P, S>
where P: Send, S: Send,

§

impl<P, S, Request> Send for AsyncResponseFuture<P, S, Request>
where S: Send, <P as AsyncPredicate<Request>>::Future: Send, <S as Service<<P as AsyncPredicate<Request>>::Request>>::Future: Send,

§

impl<P, S, Request> Send for rustmax::tower::retry::future::ResponseFuture<P, S, Request>
where Request: Send, P: Send, S: Send, <S as Service<Request>>::Future: Send, <P as Policy<Request, <S as Service<Request>>::Response, <S as Service<Request>>::Error>>::Future: Send,

§

impl<Ptr> Send for Pin<Ptr>
where Ptr: Send,

§

impl<R> Send for rustmax::futures::io::BufReader<R>
where R: Send,

§

impl<R> Send for rustmax::futures::io::Lines<R>
where R: Send,

§

impl<R> Send for rustmax::futures::io::Take<R>
where R: Send,

§

impl<R> Send for BlockRng64<R>
where <R as BlockRngCore>::Results: Send, R: Send + ?Sized,

§

impl<R> Send for BlockRng<R>
where <R as BlockRngCore>::Results: Send, R: Send,

§

impl<R> Send for UnwrapErr<R>
where R: Send,

§

impl<R> Send for IoRead<R>
where R: Send,

§

impl<R> Send for rustmax::serde_json::Deserializer<R>
where R: Send,

§

impl<R> Send for rustmax::tokio::io::BufReader<R>
where R: Send,

§

impl<R> Send for rustmax::tokio::io::Lines<R>
where R: Send,

§

impl<R> Send for rustmax::tokio::io::Split<R>
where R: Send,

§

impl<R> Send for rustmax::tokio::io::Take<R>
where R: Send,

§

impl<R> Send for ExponentialBackoff<R>
where R: Send,

§

impl<R> Send for ExponentialBackoffMaker<R>
where R: Send,

§

impl<R> Send for rustmax::std::io::BufReader<R>
where R: Send + ?Sized,

§

impl<R> Send for rustmax::std::io::Bytes<R>
where R: Send,

§

impl<R, F> Send for rustmax::tower::filter::future::ResponseFuture<R, F>
where R: Send, F: Send,

§

impl<R, Rsdr> Send for ReseedingRng<R, Rsdr>
where <R as BlockRngCore>::Results: Send, R: Send, Rsdr: Send,

§

impl<R, W> Send for rustmax::tokio::io::Join<R, W>
where R: Send, W: Send,

§

impl<RW> Send for BufStream<RW>
where RW: Send,

§

impl<Req, F> Send for rustmax::tower::buffer::Buffer<Req, F>
where Req: Send, F: Send,

§

impl<Request> Send for BufferLayer<Request>

§

impl<S = DefaultSpawn> !Send for ThreadPoolBuilder<S>

§

impl<S> Send for Host<S>
where S: Send,

§

impl<S> Send for State<S>
where S: Send,

§

impl<S> Send for LayeredFuture<S>
where S: Send, <S as Service<Request<Body>>>::Future: Send,

§

impl<S> Send for Sse<S>
where S: Send,

§

impl<S> Send for IntoMakeServiceFuture<S>
where S: Send,

§

impl<S> Send for IntoMakeService<S>
where S: Send,

§

impl<S> Send for Router<S>

§

impl<S> Send for BlockingStream<S>
where S: Send,

§

impl<S> Send for rustmax::futures::prelude::stream::PollImmediate<S>
where S: Send,

§

impl<S> Send for SplitStream<S>
where S: Send,

§

impl<S> Send for rustmax::proptest::strategy::Flatten<S>
where S: Send,

§

impl<S> Send for FlattenValueTree<S>
where S: Send, <<S as ValueTree>::Value as Strategy>::Tree: Send,

§

impl<S> Send for IndFlatten<S>
where S: Send,

§

impl<S> Send for LazyValueTree<S>
where <S as Strategy>::Tree: Send, S: Sync + Send,

§

impl<S> Send for Shuffle<S>
where S: Send,

§

impl<S> Send for LoadShed<S>
where S: Send,

§

impl<S> Send for SharedFuture<S>
where S: Send,

§

impl<S> Send for rustmax::tower::make::Shared<S>
where S: Send,

§

impl<S> Send for SpawnReady<S>
where S: Send,

§

impl<S, B> Send for WalkTree<S, B>
where S: Send, B: Send,

§

impl<S, B> Send for WalkTreePostfix<S, B>
where S: Send, B: Send,

§

impl<S, B> Send for WalkTreePrefix<S, B>
where S: Send, B: Send,

§

impl<S, C> Send for IntoMakeServiceWithConnectInfo<S, C>
where S: Send,

§

impl<S, C> Send for rustmax::axum::extract::connect_info::ResponseFuture<S, C>
where S: Send, C: Send,

§

impl<S, C> Send for PeakEwma<S, C>
where S: Send, C: Send,

§

impl<S, C> Send for PendingRequests<S, C>
where S: Send, C: Send,

§

impl<S, E> Send for MethodRouter<S, E>

§

impl<S, F> Send for rustmax::proptest::strategy::statics::Filter<S, F>
where S: Send, F: Send,

§

impl<S, F> Send for rustmax::proptest::strategy::statics::Map<S, F>
where S: Send, F: Send,

§

impl<S, F> Send for rustmax::proptest::strategy::Filter<S, F>
where S: Send, F: Sync + Send,

§

impl<S, F> Send for rustmax::proptest::strategy::FilterMap<S, F>
where S: Send, F: Sync + Send,

§

impl<S, F> Send for IndFlattenMap<S, F>
where S: Send, F: Sync + Send,

§

impl<S, F> Send for rustmax::proptest::strategy::Map<S, F>
where S: Send, F: Sync + Send,

§

impl<S, F> Send for Perturb<S, F>
where S: Send, F: Sync + Send,

§

impl<S, F> Send for PerturbValueTree<S, F>
where S: Send, F: Sync + Send,

§

impl<S, F> Send for rustmax::tower::util::AndThen<S, F>
where S: Send, F: Send,

§

impl<S, F> Send for rustmax::tower::util::MapErr<S, F>
where S: Send, F: Send,

§

impl<S, F> Send for MapFuture<S, F>
where S: Send, F: Send,

§

impl<S, F> Send for rustmax::tower::util::MapRequest<S, F>
where S: Send, F: Send,

§

impl<S, F> Send for rustmax::tower::util::MapResponse<S, F>
where S: Send, F: Send,

§

impl<S, F> Send for MapResult<S, F>
where S: Send, F: Send,

§

impl<S, F> Send for rustmax::tower::util::Then<S, F>
where S: Send, F: Send,

§

impl<S, F, Req> Send for Steer<S, F, Req>
where F: Send, Req: Send, S: Send,

§

impl<S, F, T> Send for HandleError<S, F, T>
where S: Send, F: Send,

§

impl<S, Item> Send for SplitSink<S, Item>
where Item: Send, S: Send,

§

impl<S, O> Send for rustmax::proptest::strategy::MapInto<S, O>
where S: Send, O: Send,

§

impl<S, P> Send for Hedge<S, P>
where P: Send, S: Send,

§

impl<S, Req> Send for MakeBalance<S, Req>
where S: Send,

§

impl<S, Req> Send for Oneshot<S, Req>
where S: Send, <S as Service<Req>>::Future: Send, Req: Send,

§

impl<S, Request> Send for Future<S, Request>
where <S as Service<Request>>::Future: Send,

§

impl<S, T> Send for AddExtension<S, T>
where S: Send, T: Send,

§

impl<S, T> Send for UniformArrayStrategy<S, T>
where S: Send, T: Send,

§

impl<Si1, Si2> Send for Fanout<Si1, Si2>
where Si1: Send, Si2: Send,

§

impl<Si, F> Send for SinkMapErr<Si, F>
where Si: Send, F: Send,

§

impl<Si, Item> Send for rustmax::futures::prelude::sink::Buffer<Si, Item>
where Si: Send, Item: Send,

§

impl<Si, Item, E> Send for SinkErrInto<Si, Item, E>
where Si: Send,

§

impl<Si, Item, U, Fut, F> Send for With<Si, Item, U, Fut, F>
where Si: Send, F: Send, Fut: Send,

§

impl<Si, Item, U, St, F> Send for WithFlatMap<Si, Item, U, St, F>
where Si: Send, F: Send, St: Send, Item: Send,

§

impl<Span> Send for DelimSpan<Span>
where Span: Send,

§

impl<Span> Send for Diagnostic<Span>
where Span: Send,

§

impl<Span> Send for ExpnGlobals<Span>
where Span: Send,

§

impl<Span> Send for Punct<Span>
where Span: Send,

§

impl<Span, Symbol> Send for Ident<Span, Symbol>
where Symbol: Send, Span: Send,

§

impl<Span, Symbol> Send for Literal<Span, Symbol>
where Symbol: Send, Span: Send,

§

impl<St1, St2> Send for rustmax::futures::prelude::stream::Chain<St1, St2>
where St2: Send, St1: Send,

§

impl<St1, St2> Send for rustmax::futures::prelude::stream::Select<St1, St2>
where St1: Send, St2: Send,

§

impl<St1, St2> Send for rustmax::futures::prelude::stream::Zip<St1, St2>
where St1: Send, St2: Send, <St1 as Stream>::Item: Send, <St2 as Stream>::Item: Send,

§

impl<St1, St2, Clos, State> Send for SelectWithStrategy<St1, St2, Clos, State>
where St1: Send, St2: Send, State: Send, Clos: Send,

§

impl<St> Send for rustmax::futures::prelude::stream::select_all::IntoIter<St>
where St: Send,

§

impl<St> Send for BufferUnordered<St>
where St: Send, <St as Stream>::Item: Send,

§

impl<St> Send for Buffered<St>
where St: Send, <St as Stream>::Item: Send, <<St as Stream>::Item as Future>::Output: Send,

§

impl<St> Send for rustmax::futures::prelude::stream::CatchUnwind<St>
where St: Send,

§

impl<St> Send for rustmax::futures::prelude::stream::Chunks<St>
where St: Send, <St as Stream>::Item: Send,

§

impl<St> Send for Concat<St>
where St: Send, <St as Stream>::Item: Send,

§

impl<St> Send for rustmax::futures::prelude::stream::Count<St>
where St: Send,

§

impl<St> Send for rustmax::futures::prelude::stream::Cycle<St>
where St: Send,

§

impl<St> Send for rustmax::futures::prelude::stream::Enumerate<St>
where St: Send,

§

impl<St> Send for rustmax::futures::prelude::stream::Flatten<St>
where St: Send, <St as Stream>::Item: Send,

§

impl<St> Send for rustmax::futures::prelude::stream::Fuse<St>
where St: Send,

§

impl<St> Send for IntoAsyncRead<St>
where St: Send, <St as TryStream>::Ok: Send,

§

impl<St> Send for rustmax::futures::prelude::stream::IntoStream<St>
where St: Send,

§

impl<St> Send for rustmax::futures::prelude::stream::Peekable<St>
where St: Send, <St as Stream>::Item: Send,

§

impl<St> Send for ReadyChunks<St>
where St: Send,

§

impl<St> Send for rustmax::futures::prelude::stream::SelectAll<St>
where St: Send,

§

impl<St> Send for rustmax::futures::prelude::stream::Skip<St>
where St: Send,

§

impl<St> Send for StreamFuture<St>
where St: Send,

§

impl<St> Send for rustmax::futures::prelude::stream::Take<St>
where St: Send,

§

impl<St> Send for TryBufferUnordered<St>
where St: Send, <St as TryStream>::Ok: Send,

§

impl<St> Send for TryBuffered<St>
where St: Send, <St as TryStream>::Ok: Send, <<St as TryStream>::Ok as TryFuture>::Ok: Send, <<St as TryStream>::Ok as TryFuture>::Error: Send,

§

impl<St> Send for TryChunks<St>
where St: Send, <St as TryStream>::Ok: Send,

§

impl<St> Send for TryConcat<St>
where St: Send, <St as TryStream>::Ok: Send,

§

impl<St> Send for rustmax::futures::prelude::stream::TryFlatten<St>
where St: Send, <St as TryStream>::Ok: Send,

§

impl<St> Send for TryFlattenUnordered<St>
where <<St as TryStream>::Ok as TryStream>::Error: Sized + Send, St: Send, <St as TryStream>::Ok: Send, <<St as TryStream>::Ok as TryStream>::Ok: Send,

§

impl<St> Send for TryReadyChunks<St>
where St: Send,

§

impl<St, C> Send for Collect<St, C>
where St: Send, C: Send,

§

impl<St, C> Send for TryCollect<St, C>
where St: Send, C: Send,

§

impl<St, E> Send for rustmax::futures::prelude::stream::ErrInto<St, E>
where St: Send,

§

impl<St, F> Send for rustmax::futures::prelude::stream::Inspect<St, F>
where St: Send, F: Send,

§

impl<St, F> Send for rustmax::futures::prelude::stream::InspectErr<St, F>
where St: Send, F: Send,

§

impl<St, F> Send for rustmax::futures::prelude::stream::InspectOk<St, F>
where St: Send, F: Send,

§

impl<St, F> Send for rustmax::futures::prelude::stream::Map<St, F>
where St: Send, F: Send,

§

impl<St, F> Send for rustmax::futures::prelude::stream::MapErr<St, F>
where St: Send, F: Send,

§

impl<St, F> Send for rustmax::futures::prelude::stream::MapOk<St, F>
where St: Send, F: Send,

§

impl<St, F> Send for Iterate<St, F>
where St: Send, F: Send,

§

impl<St, F> Send for rustmax::itertools::Unfold<St, F>
where F: Send, St: Send,

§

impl<St, FromA, FromB> Send for Unzip<St, FromA, FromB>
where St: Send, FromA: Send, FromB: Send,

§

impl<St, Fut> Send for rustmax::futures::prelude::stream::TakeUntil<St, Fut>
where St: Send, Fut: Send, <Fut as Future>::Output: Send,

§

impl<St, Fut, F> Send for All<St, Fut, F>
where St: Send, F: Send, Fut: Send,

§

impl<St, Fut, F> Send for rustmax::futures::prelude::stream::AndThen<St, Fut, F>
where St: Send, F: Send, Fut: Send,

§

impl<St, Fut, F> Send for rustmax::futures::prelude::stream::Any<St, Fut, F>
where St: Send, F: Send, Fut: Send,

§

impl<St, Fut, F> Send for rustmax::futures::prelude::stream::Filter<St, Fut, F>
where St: Send, F: Send, Fut: Send, <St as Stream>::Item: Send,

§

impl<St, Fut, F> Send for rustmax::futures::prelude::stream::FilterMap<St, Fut, F>
where St: Send, F: Send, Fut: Send,

§

impl<St, Fut, F> Send for ForEach<St, Fut, F>
where St: Send, F: Send, Fut: Send,

§

impl<St, Fut, F> Send for ForEachConcurrent<St, Fut, F>
where F: Send, St: Send, Fut: Send,

§

impl<St, Fut, F> Send for rustmax::futures::prelude::stream::OrElse<St, Fut, F>
where St: Send, F: Send, Fut: Send,

§

impl<St, Fut, F> Send for rustmax::futures::prelude::stream::SkipWhile<St, Fut, F>
where St: Send, F: Send, Fut: Send, <St as Stream>::Item: Send,

§

impl<St, Fut, F> Send for rustmax::futures::prelude::stream::TakeWhile<St, Fut, F>
where St: Send, F: Send, Fut: Send, <St as Stream>::Item: Send,

§

impl<St, Fut, F> Send for rustmax::futures::prelude::stream::Then<St, Fut, F>
where St: Send, F: Send, Fut: Send,

§

impl<St, Fut, F> Send for TryAll<St, Fut, F>
where St: Send, F: Send, Fut: Send,

§

impl<St, Fut, F> Send for TryAny<St, Fut, F>
where St: Send, F: Send, Fut: Send,

§

impl<St, Fut, F> Send for TryFilter<St, Fut, F>
where St: Send, F: Send, Fut: Send, <St as TryStream>::Ok: Send,

§

impl<St, Fut, F> Send for TryFilterMap<St, Fut, F>
where St: Send, F: Send, Fut: Send,

§

impl<St, Fut, F> Send for TryForEach<St, Fut, F>
where St: Send, F: Send, Fut: Send,

§

impl<St, Fut, F> Send for TryForEachConcurrent<St, Fut, F>
where F: Send, St: Send, Fut: Send,

§

impl<St, Fut, F> Send for TrySkipWhile<St, Fut, F>
where St: Send, F: Send, Fut: Send, <St as TryStream>::Ok: Send,

§

impl<St, Fut, F> Send for TryTakeWhile<St, Fut, F>
where St: Send, F: Send, Fut: Send, <St as TryStream>::Ok: Send,

§

impl<St, Fut, T, F> Send for rustmax::futures::prelude::stream::Fold<St, Fut, T, F>
where St: Send, F: Send, T: Send, Fut: Send,

§

impl<St, Fut, T, F> Send for rustmax::futures::prelude::stream::TryFold<St, Fut, T, F>
where St: Send, F: Send, T: Send, Fut: Send,

§

impl<St, S, Fut, F> Send for rustmax::futures::prelude::stream::Scan<St, S, Fut, F>
where St: Send, Fut: Send, S: Send, F: Send,

§

impl<St, Si> Send for Forward<St, Si>
where Si: Send, St: Send, <St as TryStream>::Ok: Send,

§

impl<St, U, F> Send for rustmax::futures::prelude::stream::FlatMap<St, U, F>
where St: Send, F: Send, U: Send,

§

impl<St, U, F> Send for FlatMapUnordered<St, U, F>
where St: Send, F: Send, U: Send,

§

impl<Svc, S> Send for CallAll<Svc, S>
where S: Send, Svc: Send, <S as Stream>::Item: Send, <Svc as Service<<S as Stream>::Item>>::Future: Send, <Svc as Service<<S as Stream>::Item>>::Response: Send, <Svc as Service<<S as Stream>::Item>>::Error: Send,

§

impl<Svc, S> Send for CallAllUnordered<Svc, S>
where S: Send, Svc: Send, <Svc as Service<<S as Stream>::Item>>::Future: Send, <S as Stream>::Item: Send,

§

impl<T> !Send for BoxedStrategy<T>

§

impl<T> !Send for RegexGeneratorValueTree<T>

§

impl<T> Send for LocalResult<T>
where T: Send,

§

impl<T> Send for Resettable<T>
where T: Send,

§

impl<T> Send for rustmax::crossbeam::channel::SendTimeoutError<T>
where T: Send,

§

impl<T> Send for rustmax::crossbeam::channel::TrySendError<T>
where T: Send,

§

impl<T> Send for Steal<T>
where T: Send,

§

impl<T> Send for FoldWhile<T>
where T: Send,

§

impl<T> Send for MinMaxResult<T>
where T: Send,

§

impl<T> Send for TestError<T>
where T: Send,

§

impl<T> Send for SetError<T>
where T: Send,

§

impl<T> Send for rustmax::tokio::sync::mpsc::error::SendTimeoutError<T>
where T: Send,

§

impl<T> Send for rustmax::tokio::sync::mpsc::error::TrySendError<T>
where T: Send,

§

impl<T> Send for Bound<T>
where T: Send,

§

impl<T> Send for Option<T>
where T: Send,

§

impl<T> Send for rustmax::std::sync::TryLockError<T>
where T: Send,

§

impl<T> Send for rustmax::std::sync::mpmc::SendTimeoutError<T>
where T: Send,

§

impl<T> Send for rustmax::std::sync::mpsc::TrySendError<T>
where T: Send,

§

impl<T> Send for Poll<T>
where T: Send,

§

impl<T> Send for MockConnectInfo<T>
where T: Send,

§

impl<T> Send for ConnectInfo<T>
where T: Send,

§

impl<T> Send for rustmax::axum::extract::Path<T>
where T: Send,

§

impl<T> Send for Query<T>
where T: Send,

§

impl<T> Send for Html<T>
where T: Send,

§

impl<T> Send for Extension<T>
where T: Send,

§

impl<T> Send for Form<T>
where T: Send,

§

impl<T> Send for Json<T>
where T: Send,

§

impl<T> Send for rustmax::bytes::buf::IntoIter<T>
where T: Send,

§

impl<T> Send for Limit<T>
where T: Send,

§

impl<T> Send for rustmax::bytes::buf::Take<T>
where T: Send,

§

impl<T> Send for RangedI64ValueParser<T>

§

impl<T> Send for RangedU64ValueParser<T>
where T: Send,

§

impl<T> Send for rustmax::clap::parser::Values<T>

§

impl<T> Send for rustmax::crossbeam::channel::IntoIter<T>
where T: Send,

§

impl<T> Send for rustmax::crossbeam::channel::SendError<T>
where T: Send,

§

impl<T> Send for Owned<T>
where T: Send + ?Sized,

§

impl<T> Send for CxxVector<T>
where T: Send,

§

impl<T> Send for TryFromReprError<T>
where T: Send,

§

impl<T> Send for TryIntoError<T>
where T: Send,

§

impl<T> Send for TryUnwrapError<T>
where T: Send,

§

impl<T> Send for rustmax::futures::channel::mpsc::Receiver<T>
where T: Send,

§

impl<T> Send for rustmax::futures::channel::mpsc::Sender<T>
where T: Send,

§

impl<T> Send for rustmax::futures::channel::mpsc::TrySendError<T>
where T: Send,

§

impl<T> Send for rustmax::futures::channel::mpsc::UnboundedReceiver<T>
where T: Send,

§

impl<T> Send for rustmax::futures::channel::mpsc::UnboundedSender<T>
where T: Send,

§

impl<T> Send for rustmax::futures::channel::oneshot::Receiver<T>
where T: Send,

§

impl<T> Send for rustmax::futures::channel::oneshot::Sender<T>
where T: Send,

§

impl<T> Send for AllowStdIo<T>
where T: Send,

§

impl<T> Send for rustmax::futures::io::Cursor<T>
where T: Send,

§

impl<T> Send for rustmax::futures::io::ReadHalf<T>
where T: Send,

§

impl<T> Send for rustmax::futures::io::ReuniteError<T>
where T: Send,

§

impl<T> Send for Window<T>
where T: Send,

§

impl<T> Send for rustmax::futures::io::WriteHalf<T>
where T: Send,

§

impl<T> Send for rustmax::futures::prelude::future::Pending<T>
where T: Send,

§

impl<T> Send for rustmax::futures::prelude::future::PollImmediate<T>
where T: Send,

§

impl<T> Send for rustmax::futures::prelude::future::Ready<T>
where T: Send,

§

impl<T> Send for RemoteHandle<T>
where T: Send,

§

impl<T> Send for rustmax::futures::prelude::sink::Drain<T>
where T: Send,

§

impl<T> Send for Abortable<T>
where T: Send,

§

impl<T> Send for rustmax::futures::prelude::stream::Empty<T>
where T: Send,

§

impl<T> Send for FuturesOrdered<T>
where T: Send, <T as Future>::Output: Send,

§

impl<T> Send for rustmax::futures::prelude::stream::Pending<T>
where T: Send,

§

impl<T> Send for rustmax::futures::prelude::stream::Repeat<T>
where T: Send,

§

impl<T> Send for rustmax::hyper::body::Frame<T>
where T: Send,

§

impl<T> Send for rustmax::hyper::client::conn::http1::Parts<T>
where T: Send,

§

impl<T> Send for rustmax::hyper::client::conn::TrySendError<T>
where T: Send,

§

impl<T> Send for Port<T>
where T: Send,

§

impl<T> Send for rustmax::hyper::Request<T>
where T: Send,

§

impl<T> Send for rustmax::hyper::Response<T>
where T: Send,

§

impl<T> Send for rustmax::hyper::upgrade::Parts<T>
where T: Send,

§

impl<T> Send for TupleBuffer<T>
where <T as TupleCollect>::Buffer: Send,

§

impl<T> Send for rustmax::itertools::Zip<T>
where T: Send,

§

impl<T> Send for Choice<T>
where T: Send,

§

impl<T> Send for TryFromBigIntError<T>
where T: Send,

§

impl<T> Send for ArrayValueTree<T>
where T: Send,

§

impl<T> Send for BitSetStrategy<T>
where T: Send,

§

impl<T> Send for BitSetValueTree<T>
where T: Send,

§

impl<T> Send for SampledBitSetStrategy<T>
where T: Send,

§

impl<T> Send for BTreeSetStrategy<T>
where T: Send,

§

impl<T> Send for BTreeSetValueTree<T>
where T: Send,

§

impl<T> Send for BinaryHeapStrategy<T>
where T: Send,

§

impl<T> Send for BinaryHeapValueTree<T>
where T: Send,

§

impl<T> Send for HashSetStrategy<T>
where T: Send,

§

impl<T> Send for HashSetValueTree<T>
where T: Send,

§

impl<T> Send for LinkedListStrategy<T>
where T: Send,

§

impl<T> Send for LinkedListValueTree<T>
where T: Send,

§

impl<T> Send for VecDequeStrategy<T>
where T: Send,

§

impl<T> Send for VecDequeValueTree<T>
where T: Send,

§

impl<T> Send for VecStrategy<T>
where T: Send,

§

impl<T> Send for VecValueTree<T>
where T: Send,

§

impl<T> Send for OptionStrategy<T>
where T: Sync + Send, <T as Strategy>::Value: Sync + Send,

§

impl<T> Send for OptionValueTree<T>
where <T as Strategy>::Value: Send + Sync, <T as Strategy>::Tree: Send, T: Sync + Send,

§

impl<T> Send for Just<T>
where T: Send,

§

impl<T> Send for SBoxedStrategy<T>

§

impl<T> Send for rustmax::proptest::sample::Select<T>
where T: Sync + Send,

§

impl<T> Send for SelectValueTree<T>
where T: Sync + Send,

§

impl<T> Send for Subsequence<T>
where T: Sync + Send,

§

impl<T> Send for SubsequenceValueTree<T>
where T: Sync + Send,

§

impl<T> Send for rustmax::proptest::strategy::Fuse<T>
where T: Send,

§

impl<T> Send for NoShrink<T>
where T: Send,

§

impl<T> Send for TupleUnion<T>
where T: Send,

§

impl<T> Send for TupleUnionValueTree<T>
where T: Send,

§

impl<T> Send for rustmax::proptest::strategy::Union<T>
where T: Sync + Send,

§

impl<T> Send for UnionValueTree<T>
where <T as Strategy>::Tree: Send, T: Sync + Send,

§

impl<T> Send for RegexGeneratorStrategy<T>

§

impl<T> Send for TupleValueTree<T>
where T: Send,

§

impl<T> Send for rustmax::rayon::collections::binary_heap::IntoIter<T>

§

impl<T> Send for rustmax::rayon::collections::btree_set::IntoIter<T>

§

impl<T> Send for rustmax::rayon::collections::hash_set::IntoIter<T>

§

impl<T> Send for rustmax::rayon::collections::linked_list::IntoIter<T>

§

impl<T> Send for rustmax::rayon::collections::vec_deque::IntoIter<T>

§

impl<T> Send for rustmax::rayon::iter::Empty<T>

§

impl<T> Send for MultiZip<T>
where T: Send,

§

impl<T> Send for rustmax::rayon::iter::Once<T>

§

impl<T> Send for rustmax::rayon::iter::Repeat<T>

§

impl<T> Send for rustmax::rayon::iter::RepeatN<T>

§

impl<T> Send for rustmax::rayon::option::IntoIter<T>

§

impl<T> Send for rustmax::rayon::range::Iter<T>
where T: Send,

§

impl<T> Send for rustmax::rayon::range_inclusive::Iter<T>
where T: Send,

§

impl<T> Send for rustmax::rayon::result::IntoIter<T>

§

impl<T> Send for rustmax::rayon::vec::IntoIter<T>

§

impl<T> Send for HeaderMap<T>
where T: Send,

§

impl<T> Send for rustmax::reqwest::header::IntoIter<T>
where T: Send,

§

impl<T> Send for CoreWrapper<T>
where T: Send, <T as BufferKindUser>::BufferKind: Send,

§

impl<T> Send for RtVariableCoreWrapper<T>
where T: Send, <T as BufferKindUser>::BufferKind: Send,

§

impl<T> Send for XofReaderCoreWrapper<T>
where T: Send,

§

impl<T> Send for rustmax::syn::punctuated::IntoIter<T>
where T: Send,

§

impl<T> Send for AsyncFd<T>
where T: Send,

§

impl<T> Send for AsyncFdTryNewError<T>
where T: Send,

§

impl<T> Send for rustmax::tokio::sync::broadcast::error::SendError<T>
where T: Send,

§

impl<T> Send for rustmax::tokio::sync::mpsc::error::SendError<T>
where T: Send,

§

impl<T> Send for OwnedPermit<T>
where T: Send,

§

impl<T> Send for rustmax::tokio::sync::mpsc::Receiver<T>
where T: Send,

§

impl<T> Send for rustmax::tokio::sync::mpsc::Sender<T>
where T: Send,

§

impl<T> Send for rustmax::tokio::sync::mpsc::UnboundedReceiver<T>
where T: Send,

§

impl<T> Send for rustmax::tokio::sync::mpsc::UnboundedSender<T>
where T: Send,

§

impl<T> Send for WeakSender<T>
where T: Send,

§

impl<T> Send for WeakUnboundedSender<T>
where T: Send,

§

impl<T> Send for rustmax::tokio::sync::oneshot::Receiver<T>
where T: Send,

§

impl<T> Send for rustmax::tokio::sync::oneshot::Sender<T>
where T: Send,

§

impl<T> Send for rustmax::tokio::sync::OwnedMutexGuard<T>
where T: Send + ?Sized,

§

impl<T> Send for rustmax::tokio::sync::watch::error::SendError<T>
where T: Send,

§

impl<T> Send for rustmax::tokio::sync::watch::Receiver<T>
where T: Send + Sync,

§

impl<T> Send for rustmax::tokio::sync::watch::Sender<T>
where T: Send + Sync,

§

impl<T> Send for JoinSet<T>
where T: Send,

§

impl<T> Send for rustmax::tokio::task::LocalKey<T>

§

impl<T> Send for rustmax::tokio::time::Timeout<T>
where T: Send,

§

impl<T> Send for Spanned<T>
where T: Send,

§

impl<T> Send for rustmax::tower::buffer::future::ResponseFuture<T>
where T: Send,

§

impl<T> Send for ServiceList<T>
where <T as IntoIterator>::IntoIter: Send,

§

impl<T> Send for rustmax::tower::limit::concurrency::future::ResponseFuture<T>
where T: Send,

§

impl<T> Send for ConcurrencyLimit<T>
where T: Send,

§

impl<T> Send for RateLimit<T>
where T: Send,

§

impl<T> Send for rustmax::tower::timeout::future::ResponseFuture<T>
where T: Send,

§

impl<T> Send for rustmax::tower::timeout::Timeout<T>
where T: Send,

§

impl<T> Send for rustmax::tower::util::future::optional::ResponseFuture<T>
where T: Send,

§

impl<T> Send for Optional<T>
where T: Send,

§

impl<T> Send for ServiceFn<T>
where T: Send,

§

impl<T> Send for rustmax::std::cell::OnceCell<T>
where T: Send,

§

impl<T> Send for SyncUnsafeCell<T>
where T: Send + ?Sized,

§

impl<T> Send for UnsafeCell<T>
where T: Send + ?Sized,

§

impl<T> Send for Reverse<T>
where T: Send,

§

impl<T> Send for AsyncDropInPlace<T>
where <T as AsyncDestruct>::AsyncDestructor: Send, T: ?Sized,

§

impl<T> Send for rustmax::std::future::Pending<T>

§

impl<T> Send for rustmax::std::future::Ready<T>
where T: Send,

§

impl<T> Send for rustmax::std::io::Cursor<T>
where T: Send,

§

impl<T> Send for rustmax::std::io::Take<T>
where T: Send,

§

impl<T> Send for rustmax::std::iter::Empty<T>

§

impl<T> Send for rustmax::std::iter::Once<T>
where T: Send,

§

impl<T> Send for rustmax::std::iter::Rev<T>
where T: Send,

§

impl<T> Send for Discriminant<T>

§

impl<T> Send for ManuallyDrop<T>
where T: Send + ?Sized,

§

impl<T> Send for Saturating<T>
where T: Send,

§

impl<T> Send for Wrapping<T>
where T: Send,

§

impl<T> Send for Yeet<T>
where T: Send,

§

impl<T> Send for AssertUnwindSafe<T>
where T: Send,

§

impl<T> Send for rustmax::std::result::IntoIter<T>
where T: Send,

§

impl<T> Send for rustmax::std::sync::mpmc::IntoIter<T>
where T: Send,

§

impl<T> Send for rustmax::std::sync::mpsc::IntoIter<T>
where T: Send,

§

impl<T> Send for rustmax::std::sync::mpsc::SendError<T>
where T: Send,

§

impl<T> Send for Exclusive<T>
where T: Send + ?Sized,

§

impl<T> Send for PoisonError<T>
where T: Send,

§

impl<T> Send for rustmax::std::thread::LocalKey<T>

§

impl<T> Send for PhantomData<T>
where T: Send + ?Sized,

§

impl<T> Send for MaybeUninit<T>
where T: Send,

§

impl<T> Send for Storage<T>
where T: Send,

§

impl<T> Send for Wrapper<T>
where T: Send,

§

impl<T, A = Global> !Send for UniqueRc<T, A>

§

impl<T, A> Send for rustmax::std::boxed::Box<T, A>
where A: Send, T: Send + ?Sized,

§

impl<T, A> Send for BinaryHeap<T, A>
where A: Send, T: Send,

§

impl<T, A> Send for rustmax::std::collections::binary_heap::IntoIter<T, A>
where T: Send, A: Send,

§

impl<T, A> Send for IntoIterSorted<T, A>
where A: Send, T: Send,

§

impl<T, A> Send for BTreeSet<T, A>
where A: Send, T: Send,

§

impl<T, A> Send for rustmax::std::collections::btree_set::IntoIter<T, A>
where A: Send, T: Send,

§

impl<T, A> Send for rustmax::std::collections::linked_list::IntoIter<T, A>
where T: Send, A: Send,

§

impl<T, A> Send for rustmax::std::collections::vec_deque::IntoIter<T, A>
where A: Send, T: Send,

§

impl<T, A> Send for VecDeque<T, A>
where A: Send, T: Send,

§

impl<T, A> Send for Vec<T, A>
where A: Send, T: Send,

§

impl<T, B> Send for rustmax::hyper::client::conn::http1::Connection<T, B>
where T: Send, B: Send, <B as Body>::Data: Send,

§

impl<T, B, E> Send for rustmax::hyper::client::conn::http2::Connection<T, B, E>
where <B as Body>::Error: Sized, T: Send, E: Send, B: Send, <B as Body>::Data: Send,

§

impl<T, D> Send for Storage<T, D>
where T: Send, D: Send,

§

impl<T, E> Send for Result<T, E>
where T: Send, E: Send,

§

impl<T, E> Send for TryChunksError<T, E>
where E: Send, T: Send,

§

impl<T, E> Send for TryReadyChunksError<T, E>
where E: Send, T: Send,

§

impl<T, E> Send for Tag<T, E>
where T: Send, E: Send,

§

impl<T, E> Send for TagNoCase<T, E>
where T: Send, E: Send,

§

impl<T, E> Send for TakeUntil1<T, E>
where T: Send, E: Send,

§

impl<T, E> Send for rustmax::nom::bytes::TakeUntil<T, E>
where T: Send, E: Send,

§

impl<T, E> Send for MaybeErr<T, E>
where T: Sync + Send, E: Sync + Send, <T as Strategy>::Value: Sync + Send, <E as Strategy>::Value: Sync + Send,

§

impl<T, E> Send for MaybeErrValueTree<T, E>
where <T as Strategy>::Tree: Send, T: Sync + Send, <E as Strategy>::Tree: Send, <T as Strategy>::Value: Send + Sync, <E as Strategy>::Value: Send + Sync, E: Sync + Send,

§

impl<T, E> Send for MaybeOk<T, E>
where E: Sync + Send, T: Sync + Send, <T as Strategy>::Value: Sync + Send, <E as Strategy>::Value: Sync + Send,

§

impl<T, E> Send for MaybeOkValueTree<T, E>
where <E as Strategy>::Tree: Send, E: Sync + Send, <T as Strategy>::Tree: Send, <T as Strategy>::Value: Send + Sync, <E as Strategy>::Value: Send + Sync, T: Sync + Send,

§

impl<T, E, S> Send for FromExtractor<T, E, S>
where T: Send, S: Send,

§

impl<T, Error> Send for Permutation<T, Error>
where T: Send, Error: Send,

§

impl<T, F> !Send for Recursive<T, F>

§

impl<T, F> Send for AlwaysReady<T, F>
where F: Send,

§

impl<T, F> Send for LazyJust<T, F>
where F: Send,

§

impl<T, F> Send for TaskLocalFuture<T, F>
where T: Send, F: Send,

§

impl<T, F> Send for LazyCell<T, F>
where F: Send, T: Send,

§

impl<T, F> Send for Successors<T, F>
where F: Send, T: Send,

§

impl<T, F> Send for LazyLock<T, F>
where T: Send, F: Send,

§

impl<T, F, Fut> Send for TryUnfold<T, F, Fut>
where F: Send, T: Send, Fut: Send,

§

impl<T, F, Fut> Send for rustmax::futures::prelude::stream::Unfold<T, F, Fut>
where F: Send, T: Send, Fut: Send,

§

impl<T, F, R> Send for rustmax::futures::prelude::sink::Unfold<T, F, R>
where F: Send, T: Send, R: Send,

§

impl<T, Item> Send for rustmax::futures::prelude::stream::ReuniteError<T, Item>
where Item: Send, T: Send,

§

impl<T, M> Send for Constant<T, M>
where T: Send, M: Send,

§

impl<T, N> Send for GenericArrayIter<T, N>
where T: Send,

§

impl<T, OutSize, O> Send for CtVariableCoreWrapper<T, OutSize, O>
where T: Send, OutSize: Send, O: Send,

§

impl<T, P> Send for rustmax::syn::punctuated::Pair<T, P>
where T: Send, P: Send,

§

impl<T, P> Send for IntoPairs<T, P>
where T: Send, P: Send,

§

impl<T, P> Send for Punctuated<T, P>
where T: Send, P: Send,

§

impl<T, Request> Send for ReadyOneshot<T, Request>
where T: Send,

§

impl<T, S> Send for AHashSet<T, S>
where S: Send, T: Send,

§

impl<T, S> Send for rustmax::hyper::server::conn::http1::Connection<T, S>

§

impl<T, S> Send for rustmax::hyper::server::conn::http1::Parts<T, S>
where T: Send, S: Send,

§

impl<T, S> Send for UpgradeableConnection<T, S>

§

impl<T, S> Send for HashSet<T, S>
where S: Send, T: Send,

§

impl<T, S, E> Send for rustmax::hyper::server::conn::http2::Connection<T, S, E>
where E: Send, S: Send, T: Send, <<S as HttpService<Incoming>>::ResBody as Body>::Data: Send,

§

impl<T, U> Send for rustmax::bytes::buf::Chain<T, U>
where T: Send, U: Send,

§

impl<T, U> Send for rustmax::futures::io::Chain<T, U>
where T: Send, U: Send,

§

impl<T, U> Send for ZipLongest<T, U>
where T: Send, U: Send,

§

impl<T, U> Send for AsyncFilter<T, U>
where T: Send, U: Send,

§

impl<T, U> Send for rustmax::tower::filter::Filter<T, U>
where T: Send, U: Send,

§

impl<T, U> Send for rustmax::std::io::Chain<T, U>
where T: Send, U: Send,

§

impl<T, U, E> !Send for UnsyncBoxService<T, U, E>

§

impl<T, U, E> Send for BoxCloneService<T, U, E>

§

impl<T, U, E> Send for BoxCloneSyncService<T, U, E>

§

impl<T, U, E> Send for BoxService<T, U, E>

§

impl<T, const N: usize> Send for rustmax::rayon::array::IntoIter<T, N>

§

impl<T, const N: usize> Send for rustmax::std::array::IntoIter<T, N>
where T: Send,

§

impl<T, const N: usize> Send for Mask<T, N>
where T: Send,

§

impl<T, const N: usize> Send for Simd<T, N>
where T: Send,

§

impl<TokenStream, Span> Send for Group<TokenStream, Span>
where TokenStream: Send, Span: Send,

§

impl<TokenStream, Span, Symbol> Send for TokenTree<TokenStream, Span, Symbol>
where Span: Send, Symbol: Send, TokenStream: Send,

§

impl<Tz> Send for rustmax::chrono::DateTime<Tz>
where <Tz as TimeZone>::Offset: Send,

§

impl<U> Send for NInt<U>
where U: Send,

§

impl<U> Send for PInt<U>
where U: Send,

§

impl<U> Send for AsyncFilterLayer<U>
where U: Send,

§

impl<U> Send for FilterLayer<U>
where U: Send,

§

impl<U, B> Send for UInt<U, B>
where U: Send, B: Send,

§

impl<V> Send for ShuffleValueTree<V>
where V: Send,

§

impl<V, A> Send for TArr<V, A>
where V: Send, A: Send,

§

impl<V, F, O> Send for FilterMapValueTree<V, F, O>
where V: Send, F: Sync + Send, O: Send,

§

impl<W> Send for rustmax::futures::io::BufWriter<W>
where W: Send,

§

impl<W> Send for rustmax::futures::io::LineWriter<W>
where W: Send,

§

impl<W> Send for StdFmtWrite<W>
where W: Send,

§

impl<W> Send for StdIoWrite<W>
where W: Send,

§

impl<W> Send for Ansi<W>
where W: Send,

§

impl<W> Send for NoColor<W>
where W: Send,

§

impl<W> Send for rustmax::tokio::io::BufWriter<W>
where W: Send,

§

impl<W> Send for rustmax::std::io::BufWriter<W>
where W: Send + ?Sized,

§

impl<W> Send for IntoInnerError<W>
where W: Send,

§

impl<W> Send for rustmax::std::io::LineWriter<W>
where W: Send + ?Sized,

§

impl<W, F> Send for rustmax::serde_json::Serializer<W, F>
where W: Send, F: Send,

§

impl<W, Item> Send for IntoSink<W, Item>
where W: Send, Item: Send,

§

impl<X> Send for Uniform<X>
where <X as SampleUniform>::Sampler: Send,

§

impl<X> Send for UniformFloat<X>
where X: Send,

§

impl<X> Send for UniformInt<X>
where X: Send,

§

impl<X> Send for WeightedIndex<X>
where X: Send, <X as SampleUniform>::Sampler: Send,

§

impl<Y, R> Send for CoroutineState<Y, R>
where Y: Send, R: Send,

§

impl<const N: usize> Send for GetManyMutError<N>

§

impl<const N: usize> Send for LaneCount<N>