kvarn::prelude::utils::prelude::compact_str::core::marker

Trait Send

1.6.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.0.0 · source§

impl !Send for kvarn::prelude::utils::prelude::fmt::Arguments<'_>

source§

impl !Send for LocalWaker

1.26.0 · source§

impl !Send for Args

1.26.0 · source§

impl !Send for ArgsOs

source§

impl Send for CompressedResponse

source§

impl Send for LazyRequestBody

source§

impl Send for Collection

source§

impl Send for kvarn::shutdown::Manager

§

impl Send for kvarn::prelude::Bytes

§

impl Send for BytesMut

§

impl Send for kvarn::prelude::utils::prelude::compact_str::Drain<'_>

source§

impl Send for kvarn::prelude::utils::prelude::compact_str::core::ffi::c_str::Bytes<'_>

1.36.0 · source§

impl Send for Waker

1.6.0 · source§

impl Send for alloc::string::Drain<'_>

§

impl Send for AbortHandle

§

impl Send for Algorithm

§

impl Send for AtomicWaker

§

impl Send for AtomicWaker

§

impl Send for CCtx<'_>

§

impl Send for Collector

§

impl Send for Context

§

impl Send for DCtx<'_>

§

impl Send for EcdsaKeyPair

§

impl Send for Ed25519KeyPair

§

impl Send for Key

§

impl Send for KeyPair

§

impl Send for Parker

§

impl Send for PrivateKey

§

impl Send for PublicKey

§

impl Send for PublicKey

§

impl Send for PublicKey

§

impl Send for Select<'_>

§

impl Send for Unparker

1.44.0 · source§

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

1.44.0 · source§

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

§

impl<'a> Send for CDict<'a>

§

impl<'a> Send for DDict<'a>

§

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

§

impl<'a, 'b, K, Q, V, S, A> Send for OccupiedEntryRef<'a, 'b, K, Q, V, S, A>
where K: Send, Q: Sync + ?Sized, V: Send, S: Send, A: Send + Allocator,

§

impl<'a, 'i, K, S, M> Send for Iter<'i, K, S, M>
where K: 'a + Eq + Hash + Send, S: 'a + BuildHasher + Clone, M: Map<'a, K, (), S>,

§

impl<'a, 'i, K, V> Send for Iter<'i, K, V>
where K: 'a + Eq + Hash + Send, V: 'a + Send,

§

impl<'a, 'i, K, V, S, M> Send for Iter<'i, K, V, S, M>
where K: 'a + Eq + Hash + Send, V: 'a + Send, S: 'a + BuildHasher + Clone, M: Map<'a, K, V, S>,

§

impl<'a, 'i, K, V, S, M> Send for IterMut<'i, K, V, S, M>
where K: 'a + Eq + Hash + Send, V: 'a + Send, S: 'a + BuildHasher + Clone, M: Map<'a, K, V, S>,

§

impl<'a, K, V> Send for OccupiedEntry<'a, K, V>
where K: Eq + Hash + Sync, V: Sync,

§

impl<'a, K, V> Send for Ref<'a, K, V>
where K: Eq + Hash + Sync, V: Sync,

§

impl<'a, K, V> Send for RefMulti<'a, K, V>
where K: Eq + Hash + Sync, V: Sync,

§

impl<'a, K, V> Send for RefMut<'a, K, V>
where K: Eq + Hash + Sync, V: Sync,

§

impl<'a, K, V> Send for RefMutMulti<'a, K, V>
where K: Eq + Hash + Sync, V: Sync,

§

impl<'a, K, V> Send for VacantEntry<'a, K, V>
where K: Eq + Hash + Sync, V: Sync,

§

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

§

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

§

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

§

impl<'a, T> Send for kvarn::prelude::utils::prelude::header::Drain<'a, T>
where T: Send,

§

impl<'a, T> Send for kvarn::prelude::utils::prelude::header::Iter<'a, T>
where T: Sync,

§

impl<'a, T> Send for kvarn::prelude::utils::prelude::header::IterMut<'a, T>
where T: Send,

§

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

§

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

§

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

§

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

§

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

§

impl<A, B> Send for ArcUnion<A, B>
where A: Sync + Send, B: Send + Sync,

source§

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

§

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

§

impl<Fut> Send for IntoIter<Fut>
where Fut: Send + Unpin,

§

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

§

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

§

impl<H, T> Send for ThinArc<H, T>
where H: Sync + Send, T: Sync + Send,

§

impl<Id> Send for DecapsulationKey<Id>
where Id: AlgorithmIdentifier,

§

impl<Id> Send for EncapsulationKey<Id>
where Id: AlgorithmIdentifier,

§

impl<K, S> Send for OwningIter<K, S>
where K: Eq + Hash + Send, S: BuildHasher + Clone + Send,

§

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

§

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

§

impl<K, V, S> Send for Cache<K, V, S>
where K: Send + Sync, V: Send + Sync, S: Send,

§

impl<K, V, S> Send for OwningIter<K, V, S>
where K: Eq + Hash + Send, V: Send, S: BuildHasher + Clone + Send,

§

impl<K, V, S> Send for SegmentedCache<K, V, S>
where K: Send + Sync, V: Send + Sync, S: Send,

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<S, C> Send for IoUring<S, C>
where S: EntryMarker, C: EntryMarker,

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 std::sync::mutex::MappedMutexGuard<'_, T>
where T: ?Sized,

1.0.0 · source§

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

source§

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

source§

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

source§

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

1.0.0 · source§

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

1.0.0 · source§

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

1.0.0 · source§

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

§

impl<T> Send for kvarn::prelude::Mutex<T>
where T: Send + ?Sized,

§

impl<T> Send for kvarn::prelude::RwLock<T>
where T: Send + ?Sized,

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.28.0 · source§

impl<T> Send for NonZero<T>

1.31.0 · source§

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

1.0.0 · source§

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

1.0.0 · source§

impl<T> Send for kvarn::prelude::utils::prelude::compact_str::core::slice::Iter<'_, T>
where T: Sync,

1.0.0 · source§

impl<T> Send for kvarn::prelude::utils::prelude::compact_str::core::slice::IterMut<'_, T>
where T: Send,

1.31.0 · source§

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

1.31.0 · source§

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

1.0.0 · source§

impl<T> Send for AtomicPtr<T>

Available on target_has_atomic_load_store="ptr" only.
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 alloc::collections::linked_list::Iter<'_, T>
where T: Sync,

1.0.0 · source§

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

source§

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

source§

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

1.0.0 · source§

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

1.0.0 · source§

impl<T> Send for 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 std::sync::mutex::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 std::sync::rwlock::RwLock<T>
where T: Send + ?Sized,

1.29.0 · source§

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

§

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

§

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

§

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

§

impl<T> Send for Bucket<T>

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<T> Send for OffsetArc<T>
where T: Sync + Send,

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

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 alloc::rc::Weak<T, A>
where A: Allocator, T: ?Sized,

1.0.0 · source§

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

source§

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

source§

impl<T, A> Send for 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 alloc::collections::vec_deque::drain::Drain<'_, T, A>
where T: Send, A: Allocator + Send,

1.4.0 · source§

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

1.6.0 · source§

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

1.0.0 · source§

impl<T, A> Send for alloc::vec::into_iter::IntoIter<T, A>
where T: Send, A: Allocator + Send,

§

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

§

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

§

impl<T, A> Send for RawDrain<'_, T, A>
where A: Allocator + Send, T: Send,

§

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

§

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

§

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

§

impl<T, R> Send for Once<T, R>
where T: Send,

§

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

§

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

§

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

§

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

§

impl<T, const N: usize> Send for AtomicTagPtr<T, N>

Auto implementors§

§

impl !Send for Body

§

impl !Send for HttpConnection

§

impl !Send for ResponseBodyPipe

§

impl !Send for ResponsePipe

§

impl !Send for Encryption

§

impl !Send for kvarn::Incoming

§

impl !Send for SendKind

§

impl !Send for TcpStreamAsyncWrapper

§

impl !Send for Extensions

§

impl !Send for Host

§

impl !Send for CacheReply

§

impl !Send for FatResponse

§

impl !Send for File

§

impl !Send for kvarn::prelude::networking::TcpListener

§

impl !Send for RawWaker

§

impl Send for kvarn::application::Error

§

impl Send for H2SendResponse

§

impl Send for PushedResponsePipe

§

impl Send for CachePreferenceError

§

impl Send for ClientCachePreference

§

impl Send for CompressPreference

§

impl Send for PreferredCompression

§

impl Send for ServerCachePreference

§

impl Send for UriKey

§

impl Send for Value

§

impl Send for PluginResponseKind

§

impl Send for kvarn::encryption::Error

§

impl Send for BindIpVersion

§

impl Send for CacheAction

§

impl Send for CertificateError

§

impl Send for Action

§

impl Send for kvarn::websocket::Error

§

impl Send for IpAddr

§

impl Send for SocketAddr

§

impl Send for BytesCow

§

impl Send for CacheControlError

§

impl Send for kvarn::prelude::utils::parse::Error

§

impl Send for RequestParseStage

§

impl Send for SanitizeError

§

impl Send for kvarn::prelude::utils::prelude::fmt::Alignment

§

impl Send for ErrorKind

§

impl Send for SeekFrom

§

impl Send for Ipv6MulticastScope

§

impl Send for Shutdown

§

impl Send for ToCompactStringError

§

impl Send for AsciiChar

§

impl Send for kvarn::prelude::utils::prelude::compact_str::core::cmp::Ordering

§

impl Send for Infallible

§

impl Send for c_void

§

impl Send for BasicBlock

§

impl Send for UnwindTerminateReason

§

impl Send for FpCategory

§

impl Send for IntErrorKind

§

impl Send for SearchStep

§

impl Send for kvarn::prelude::utils::prelude::compact_str::core::sync::atomic::Ordering

§

impl Send for ByteBody

§

impl Send for CompressionOptions

§

impl Send for PathQuery

§

impl Send for AllowList

§

impl Send for ComputedRule

§

impl Send for Rule

§

impl Send for ValueSet

§

impl Send for kvarn::ctl::Arguments

§

impl Send for PluginResponse

§

impl Send for Plugins

§

impl Send for Id

§

impl Send for CollectionBuilder

§

impl Send for Options

§

impl Send for kvarn::limiting::Manager

§

impl Send for Metadata

§

impl Send for PortDescriptor

§

impl Send for RunConfig

§

impl Send for Settings

§

impl Send for VariedResponse

§

impl Send for OffsetDateTime

§

impl Send for OpenOptions

§

impl Send for Mime

§

impl Send for kvarn::prelude::networking::UdpSocket

§

impl Send for CompactString

§

impl Send for Duration

§

impl Send for HeaderName

§

impl Send for HeaderValue

§

impl Send for Instant

§

impl Send for Method

§

impl Send for Path

§

impl Send for PathBuf

§

impl Send for StatusCode

§

impl Send for Uri

§

impl Send for Version

§

impl Send for WriteableBytes

§

impl Send for CacheControl

§

impl Send for CriticalRequestComponents

§

impl Send for PresentArguments

§

impl Send for PresentExtensions

§

impl Send for PresentExtensionsIter

§

impl Send for UninitSlice

§

impl Send for kvarn::prelude::utils::prelude::fmt::Error

§

impl Send for InvalidHeaderName

§

impl Send for InvalidHeaderValue

§

impl Send for MaxSizeReached

§

impl Send for ToStrError

§

impl Send for kvarn::prelude::utils::prelude::io::Empty

§

impl Send for kvarn::prelude::utils::prelude::io::Error

§

impl Send for kvarn::prelude::utils::prelude::io::Repeat

§

impl Send for Sink

§

impl Send for Stderr

§

impl Send for Stdin

§

impl Send for Stdout

§

impl Send for WriterPanicked

§

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 kvarn::prelude::utils::prelude::net::TcpListener

§

impl Send for TcpStream

§

impl Send for kvarn::prelude::utils::prelude::net::UdpSocket

§

impl Send for ParseBoolError

§

impl Send for Utf8Error

§

impl Send for Authority

§

impl Send for Builder

§

impl Send for InvalidUri

§

impl Send for InvalidUriParts

§

impl Send for Parts

§

impl Send for PathAndQuery

§

impl Send for Scheme

§

impl Send for ReserveError

§

impl Send for Utf16Error

§

impl Send for AllocError

§

impl Send for Layout

§

impl Send for LayoutError

§

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 kvarn::prelude::utils::prelude::compact_str::core::ascii::EscapeDefault

§

impl Send for BorrowError

§

impl Send for BorrowMutError

§

impl Send for CharTryFromError

§

impl Send for DecodeUtf16Error

§

impl Send for kvarn::prelude::utils::prelude::compact_str::core::char::EscapeDebug

§

impl Send for kvarn::prelude::utils::prelude::compact_str::core::char::EscapeDefault

§

impl Send for kvarn::prelude::utils::prelude::compact_str::core::char::EscapeUnicode

§

impl Send for ParseCharError

§

impl Send for ToLowercase

§

impl Send for ToUppercase

§

impl Send for TryFromCharError

§

impl Send for CStr

§

impl Send for FromBytesUntilNulError

§

impl Send for FromBytesWithNulError

§

impl Send for SipHasher

§

impl Send for ReturnToArg

§

impl Send for UnwindActionArg

§

impl Send for Assume

§

impl Send for ParseFloatError

§

impl Send for ParseIntError

§

impl Send for TryFromIntError

§

impl Send for kvarn::prelude::utils::prelude::compact_str::core::ptr::Alignment

§

impl Send for RangeFull

§

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 RawWakerVTable

§

impl Send for TryFromFloatSecsError

§

impl Send for PhantomPinned

§

impl Send for Big8x3

§

impl Send for Big32x40

§

impl Send for Decoded

§

impl Send for FullDecoded

§

impl Send for Maybe

§

impl Send for NoRuntime

§

impl Send for Number

§

impl Send for Runtime

§

impl Send for Sign

§

impl Send for TryCaptureWithDebug

§

impl Send for TryCaptureWithoutDebug

§

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

§

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

§

impl<'a> !Send for kvarn::prelude::Context<'a>

§

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

§

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

§

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

§

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

§

impl<'a> !Send for kvarn::prelude::utils::prelude::compact_str::core::error::Request<'a>

§

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

§

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

§

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

§

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

§

impl<'a> Send for MethodAllowList<'a>

§

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

§

impl<'a> Send for CertificateDer<'a>

§

impl<'a> Send for ReadBuf<'a>

§

impl<'a> Send for Query<'a>

§

impl<'a> Send for QueryPair<'a>

§

impl<'a> Send for QueryPairIter<'a>

§

impl<'a> Send for PresentArgumentsIter<'a>

§

impl<'a> Send for QuotedStrSplitIter<'a>

§

impl<'a> Send for ValueQualitySet<'a>

§

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

§

impl<'a> Send for kvarn::prelude::utils::prelude::net::Incoming<'a>

§

impl<'a> Send for kvarn::prelude::utils::prelude::str::Bytes<'a>

§

impl<'a> Send for CharIndices<'a>

§

impl<'a> Send for Chars<'a>

§

impl<'a> Send for EncodeUtf16<'a>

§

impl<'a> Send for kvarn::prelude::utils::prelude::str::EscapeDebug<'a>

§

impl<'a> Send for kvarn::prelude::utils::prelude::str::EscapeDefault<'a>

§

impl<'a> Send for kvarn::prelude::utils::prelude::str::EscapeUnicode<'a>

§

impl<'a> Send for kvarn::prelude::utils::prelude::str::Lines<'a>

§

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

§

impl<'a> Send for SplitAsciiWhitespace<'a>

§

impl<'a> Send for SplitWhitespace<'a>

§

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

§

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

§

impl<'a> Send for Location<'a>

§

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

§

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

§

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

§

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

§

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 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, 'f> !Send for VaList<'a, 'f>

§

impl<'a, A> Send for kvarn::prelude::utils::prelude::compact_str::core::option::Iter<'a, A>
where A: Sync,

§

impl<'a, A> Send for kvarn::prelude::utils::prelude::compact_str::core::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, F> Send for CharPredicateSearcher<'a, F>
where F: Send,

§

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

§

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

§

impl<'a, P> Send for 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 kvarn::prelude::utils::prelude::str::RSplit<'a, P>
where <P as Pattern>::Searcher<'a>: Send,

§

impl<'a, P> Send for kvarn::prelude::utils::prelude::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 kvarn::prelude::utils::prelude::str::Split<'a, P>
where <P as Pattern>::Searcher<'a>: Send,

§

impl<'a, P> Send for kvarn::prelude::utils::prelude::str::SplitInclusive<'a, P>
where <P as Pattern>::Searcher<'a>: Send,

§

impl<'a, P> Send for kvarn::prelude::utils::prelude::str::SplitN<'a, P>
where <P as Pattern>::Searcher<'a>: Send,

§

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

§

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

§

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

§

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