wasmtime_environ::__core::prelude::rust_2021

Trait Send

1.55.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 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 wasmtime_environ::__core::ffi::c_str::Bytes<'_>

1.36.0 · Source§

impl Send for Waker

1.6.0 · Source§

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

1.44.0 · Source§

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

1.44.0 · Source§

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

Source§

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

Source§

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

Source§

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

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<K, V, S, A> Send for RawOccupiedEntryMut<'_, K, V, S, A>
where K: Send, V: Send, S: Send, A: Send + Allocator,

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

1.0.0 · Source§

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

Source§

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

Source§

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

1.0.0 · Source§

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

1.0.0 · Source§

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

Source§

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

1.0.0 · Source§

impl<T> Send for &T
where T: Sync + ?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 wasmtime_environ::__core::slice::Iter<'_, T>
where T: Sync,

1.0.0 · Source§

impl<T> Send for wasmtime_environ::__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>

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.70.0 · Source§

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

1.0.0 · Source§

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

1.0.0 · Source§

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

Source§

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

1.29.0 · Source§

impl<T> Send for JoinHandle<T>

1.0.0 · Source§

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

Source§

impl<T, A> !Send for UniqueRc<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,

Source§

impl<T, A> Send for allocator_api2::stable::boxed::Box<T, A>
where A: Allocator + Send, T: Send + ?Sized,

Source§

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

Source§

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

Source§

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

1.6.0 · Source§

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

1.0.0 · Source§

impl<T, A> Send for wasmtime_environ::prelude::vec::IntoIter<T, A>
where T: Send, A: Allocator + Send,

Source§

impl<T, A> Send for 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.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 alloc::sync::Weak<T, A>
where T: Sync + Send + ?Sized, A: Allocator + Send,

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

impl<T: Send + Sync + ?Sized> Send for RwLockWriteGuardArc<T>

impl<T: Send + Sync> Send for RwLockReadGuardArc<T>

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

impl<T: Send + ?Sized> Send for LockArc<T>

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

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

impl<T: Send + ?Sized> Send for MutexGuardArc<T>

impl<T: Send + ?Sized> Send for RwLock<T>

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

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

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

impl Send for AtomicWaker

impl Send for Bump

impl Send for Bytes

impl Send for BytesMut

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

impl<T: Send> Send for ConcurrentQueue<T>

impl Send for Select<'_>

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

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

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

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

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

impl Send for Collector

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

impl Send for Parker

impl Send for Unparker

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

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

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

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

impl<T: Send> Send for Event<T>

impl<T: Send> Send for EventListener<T>

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

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

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

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

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

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

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

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

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

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

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

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

impl<'a, T: Send> Send for Drain<'a, T>

impl<'a, T: Send> Send for IterMut<'a, T>

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

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

impl<'a, T: Sync> Send for Iter<'a, T>

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

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

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

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

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

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

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

impl<'a, K: Send, V: Send> Send for Iter<'a, K, V>

impl<'a, K: Send, V: Send> Send for IterMut<'a, K, V>

impl<K: Send, V: Send, S: Send> Send for LruCache<K, V, S>

impl<T: Send> Send for Out<'_, T>

impl<T, C> Send for OwnedRef<T, C>
where T: Sync + Clear + Default, C: Config,

impl<T, C> Send for OwnedRefMut<T, C>
where T: Sync + Clear + Default, C: Config,

impl<T, C> Send for OwnedEntry<T, C>
where T: Sync, C: Config,

impl<T, C> Send for Pool<T, C>
where T: Send + Clear + Default, C: Config,

impl<T: Send, C: Config> Send for Slab<T, C>

impl Send for AbortHandle

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

impl<T> Send for Empty<T>

impl<T> Send for Pending<T>

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

impl Send for ValRaw

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

impl Send for CCtx<'_>

impl Send for DCtx<'_>

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

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

Auto implementors§

§

impl !Send for RawWaker

§

impl Send for wasmtime_environ::component::dfg::CoreDef

§

impl Send for wasmtime_environ::component::dfg::Export

§

impl Send for Instance

§

impl Send for SideEffect

§

impl Send for wasmtime_environ::component::dfg::Trampoline

§

impl Send for ComponentItem

§

impl Send for wasmtime_environ::component::CoreDef

§

impl Send for wasmtime_environ::component::Export

§

impl Send for FixedEncoding

§

impl Send for FlatType

§

impl Send for GlobalInitializer

§

impl Send for InstantiateModule

§

impl Send for InterfaceType

§

impl Send for StringEncoding

§

impl Send for wasmtime_environ::component::Trampoline

§

impl Send for Transcode

§

impl Send for TypeDef

§

impl Send for Collector

§

impl Send for CompileError

§

impl Send for ConstOp

§

impl Send for EngineOrModuleTypeIndex

§

impl Send for EntityIndex

§

impl Send for EntityType

§

impl Send for GcLayout

§

impl Send for HostCall

§

impl Send for IndexType

§

impl Send for Initializer

§

impl Send for MemoryInitialization

§

impl Send for ObjectKind

§

impl Send for RelocationTarget

§

impl Send for SettingKind

§

impl Send for TableInitialValue

§

impl Send for TableSegmentElements

§

impl Send for Trap

§

impl Send for TrapSentinel

§

impl Send for VMGcKind

§

impl Send for WasmCompositeInnerType

§

impl Send for WasmError

§

impl Send for WasmHeapBottomType

§

impl Send for WasmHeapTopType

§

impl Send for WasmHeapType

§

impl Send for WasmStorageType

§

impl Send for WasmValType

§

impl Send for Import

§

impl Send for LibCall

§

impl Send for AsciiChar

§

impl Send for wasmtime_environ::__core::cmp::Ordering

§

impl Send for Infallible

§

impl Send for c_void

§

impl Send for wasmtime_environ::__core::fmt::Alignment

§

impl Send for DebugAsHex

§

impl Send for wasmtime_environ::__core::fmt::Sign

§

impl Send for BasicBlock

§

impl Send for UnwindTerminateReason

§

impl Send for IpAddr

§

impl Send for Ipv6MulticastScope

§

impl Send for SocketAddr

§

impl Send for FpCategory

§

impl Send for IntErrorKind

§

impl Send for GetManyMutError

§

impl Send for SearchStep

§

impl Send for wasmtime_environ::__core::sync::atomic::Ordering

§

impl Send for AdapterId

§

impl Send for AdapterModuleId

§

impl Send for CallbackId

§

impl Send for wasmtime_environ::component::dfg::CanonicalOptions

§

impl Send for ComponentDfg

§

impl Send for FutureInfo

§

impl Send for InstanceId

§

impl Send for MemoryId

§

impl Send for PostReturnId

§

impl Send for ReallocId

§

impl Send for wasmtime_environ::component::dfg::Resource

§

impl Send for StreamInfo

§

impl Send for Adapter

§

impl Send for AdapterOptions

§

impl Send for CanonicalAbiInfo

§

impl Send for wasmtime_environ::component::CanonicalOptions

§

impl Send for CompiledComponentInfo

§

impl Send for Component

§

impl Send for ComponentArtifacts

§

impl Send for ComponentBuiltinFunctionIndex

§

impl Send for ComponentFuncIndex

§

impl Send for ComponentIndex

§

impl Send for ComponentInstanceIndex

§

impl Send for ComponentTranslation

§

impl Send for ComponentTypeIndex

§

impl Send for ComponentTypes

§

impl Send for ComponentTypesBuilder

§

impl Send for ComponentUpvarIndex

§

impl Send for DefinedResourceIndex

§

impl Send for ExportIndex

§

impl Send for ExtractCallback

§

impl Send for ExtractMemory

§

impl Send for ExtractPostReturn

§

impl Send for ExtractRealloc

§

impl Send for ImportIndex

§

impl Send for LoweredIndex

§

impl Send for ModuleIndex

§

impl Send for ModuleInstanceIndex

§

impl Send for ModuleUpvarIndex

§

impl Send for NameMapNoIntern

§

impl Send for RecordField

§

impl Send for wasmtime_environ::component::Resource

§

impl Send for ResourceIndex

§

impl Send for ResourcesBuilder

§

impl Send for RuntimeCallbackIndex

§

impl Send for RuntimeComponentInstanceIndex

§

impl Send for RuntimeImportIndex

§

impl Send for RuntimeInstanceIndex

§

impl Send for RuntimeMemoryIndex

§

impl Send for RuntimePostReturnIndex

§

impl Send for RuntimeReallocIndex

§

impl Send for StaticComponentIndex

§

impl Send for TrampolineIndex

§

impl Send for TypeComponent

§

impl Send for TypeComponentGlobalErrorContextTableIndex

§

impl Send for TypeComponentIndex

§

impl Send for TypeComponentInstance

§

impl Send for TypeComponentInstanceIndex

§

impl Send for TypeComponentLocalErrorContextTableIndex

§

impl Send for TypeEnum

§

impl Send for TypeEnumIndex

§

impl Send for TypeErrorContextTable

§

impl Send for TypeFlags

§

impl Send for TypeFlagsIndex

§

impl Send for TypeFunc

§

impl Send for TypeFuncIndex

§

impl Send for TypeFuture

§

impl Send for TypeFutureIndex

§

impl Send for TypeFutureTable

§

impl Send for TypeFutureTableIndex

§

impl Send for TypeList

§

impl Send for TypeListIndex

§

impl Send for TypeModule

§

impl Send for TypeModuleIndex

§

impl Send for TypeOption

§

impl Send for TypeOptionIndex

§

impl Send for TypeRecord

§

impl Send for TypeRecordIndex

§

impl Send for TypeResourceTable

§

impl Send for TypeResourceTableIndex

§

impl Send for TypeResult

§

impl Send for TypeResultIndex

§

impl Send for TypeStream

§

impl Send for TypeStreamIndex

§

impl Send for TypeStreamTable

§

impl Send for TypeStreamTableIndex

§

impl Send for TypeTaskReturn

§

impl Send for TypeTaskReturnIndex

§

impl Send for TypeTuple

§

impl Send for TypeTupleIndex

§

impl Send for TypeVariant

§

impl Send for TypeVariantIndex

§

impl Send for VariantInfo

§

impl Send for DrcTypeLayouts

§

impl Send for NullTypeLayouts

§

impl Send for ObjectCrateErrorWrapper

§

impl Send for String

§

impl Send for AddressMapSection

§

impl Send for BuiltinFunctionIndex

§

impl Send for CompiledFunctionInfo

§

impl Send for CompiledModuleInfo

§

impl Send for ConfigTunables

§

impl Send for ConstExpr

§

impl Send for DataIndex

§

impl Send for DefinedFuncIndex

§

impl Send for DefinedGlobalIndex

§

impl Send for DefinedMemoryIndex

§

impl Send for DefinedTableIndex

§

impl Send for DefinedTagIndex

§

impl Send for ElemIndex

§

impl Send for EngineInternedRecGroupIndex

§

impl Send for FilePos

§

impl Send for FuncIndex

§

impl Send for FuncRefIndex

§

impl Send for FunctionLoc

§

impl Send for FunctionMetadata

§

impl Send for FunctionName

§

impl Send for FunctionType

§

impl Send for GcArrayLayout

§

impl Send for GcStructLayout

§

impl Send for Global

§

impl Send for GlobalIndex

§

impl Send for HostPtr

§

impl Send for InstructionAddressMap

§

impl Send for Limits

§

impl Send for Memory

§

impl Send for MemoryIndex

§

impl Send for MemoryInitializer

§

impl Send for Metadata

§

impl Send for wasmtime_environ::Module

§

impl Send for ModuleInternedRecGroupIndex

§

impl Send for ModuleInternedTypeIndex

§

impl Send for ModuleTypes

§

impl Send for ModuleTypesBuilder

§

impl Send for OwnedMemoryIndex

§

impl Send for RecGroupRelativeTypeIndex

§

impl Send for Setting

§

impl Send for SizeOverflow

§

impl Send for StackMap

§

impl Send for StackMapInformation

§

impl Send for StaticMemoryInitializer

§

impl Send for StaticModuleIndex

§

impl Send for Table

§

impl Send for TableIndex

§

impl Send for TableInitialization

§

impl Send for TableSegment

§

impl Send for Tag

§

impl Send for TagIndex

§

impl Send for TrapEncodingBuilder

§

impl Send for TrapInformation

§

impl Send for Tunables

§

impl Send for TypeIndex

§

impl Send for VMSharedTypeIndex

§

impl Send for WasmArrayType

§

impl Send for WasmCompositeType

§

impl Send for WasmContType

§

impl Send for WasmFieldType

§

impl Send for WasmFileInfo

§

impl Send for WasmFuncType

§

impl Send for WasmFunctionInfo

§

impl Send for WasmRecGroup

§

impl Send for WasmRefType

§

impl Send for WasmStructType

§

impl Send for WasmSubType

§

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 wasmtime_environ::__core::ascii::EscapeDefault

§

impl Send for BorrowError

§

impl Send for BorrowMutError

§

impl Send for CharTryFromError

§

impl Send for DecodeUtf16Error

§

impl Send for wasmtime_environ::__core::char::EscapeDebug

§

impl Send for wasmtime_environ::__core::char::EscapeDefault

§

impl Send for wasmtime_environ::__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 Error

§

impl Send for FormattingOptions

§

impl Send for SipHasher

§

impl Send for ReturnToArg

§

impl Send for UnwindActionArg

§

impl Send for PhantomPinned

§

impl Send for Assume

§

impl Send for AddrParseError

§

impl Send for Ipv4Addr

§

impl Send for Ipv6Addr

§

impl Send for SocketAddrV4

§

impl Send for SocketAddrV6

§

impl Send for ParseFloatError

§

impl Send for ParseIntError

§

impl Send for TryFromIntError

§

impl Send for RangeFull

§

impl Send for wasmtime_environ::__core::ptr::Alignment

§

impl Send for ParseBoolError

§

impl Send for Utf8Error

§

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 Duration

§

impl Send for TryFromFloatSecsError

§

impl Send for Big8x3

§

impl Send for Big32x40

§

impl Send for Decoded

§

impl Send for FullDecoded

§

impl Send for Number

§

impl Send for Sign

§

impl Send for TryCaptureWithDebug

§

impl Send for TryCaptureWithoutDebug

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<'a> Send for FlagValue<'a>

§

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

§

impl<'a> Send for FlatTypes<'a>

§

impl<'a> Send for wasmtime_environ::fact::Module<'a>

§

impl<'a> Send for DebugInfoData<'a>

§

impl<'a> Send for FunctionBodyData<'a>

§

impl<'a> Send for NameSection<'a>

§

impl<'a> Send for ObjectBuilder<'a>

§

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

§

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

§

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

§

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

§

impl<'a> Send for wasmtime_environ::__core::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 wasmtime_environ::__core::str::EscapeDebug<'a>

§

impl<'a> Send for wasmtime_environ::__core::str::EscapeDefault<'a>

§

impl<'a> Send for wasmtime_environ::__core::str::EscapeUnicode<'a>

§

impl<'a> Send for 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 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, 'data> !Send for Translator<'a, 'data>

§

impl<'a, 'data> Send for ModuleEnvironment<'a, 'data>

§

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

§

impl<'a, A> Send for wasmtime_environ::__core::option::Iter<'a, A>
where A: Sync,

§

impl<'a, A> Send for wasmtime_environ::__core::option::IterMut<'a, A>
where A: Send,

§

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

§

impl<'a, F> Send for CharPredicateSearcher<'a, F>
where F: 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, K, V> Send for wasmtime_environ::Iter<'a, K, V>
where K: Send, V: Sync,

§

impl<'a, K, V> Send for wasmtime_environ::IterMut<'a, K, V>
where K: Send, V: 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 wasmtime_environ::__core::str::RSplit<'a, P>
where <P as Pattern>::Searcher<'a>: Send,

§

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

§

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

§

impl<'a, P> Send for wasmtime_environ::__core::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 wasmtime_environ::__core::result::Iter<'a, T>
where T: Sync,

§

impl<'a, T> Send for wasmtime_environ::__core::result::IterMut<'a, T>
where T: Send,

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<'a, T, P> Send for wasmtime_environ::__core::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 wasmtime_environ::__core::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 wasmtime_environ::__core::slice::Split<'a, T, P>
where P: Send, T: Sync,

§

impl<'a, T, P> Send for wasmtime_environ::__core::slice::SplitInclusive<'a, T, P>
where P: Send, T: Sync,

§

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

§

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

§

impl<'a, T, P> Send for wasmtime_environ::__core::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, const N: usize> !Send for ArrayWindows<'a, T, N>

§

impl<'a, T, const N: usize> Send for wasmtime_environ::__core::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, const N: usize> Send for CharArraySearcher<'a, N>

§

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

§

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

§

impl<'data> Send for ModuleTranslation<'data>

§

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

§

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

§

impl<A> Send for Repeat<A>
where A: Send,

§

impl<A> Send for RepeatN<A>
where A: Send,

§

impl<A> Send for wasmtime_environ::__core::option::IntoIter<A>
where A: Send,

§

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, B> Send for Chain<A, B>
where A: Send, B: Send,

§

impl<A, B> Send for Zip<A, B>
where A: Send, B: Send,

§

impl<B, C> Send for ControlFlow<B, C>
where C: Send, B: Send,

§

impl<E> Send for IterEntityRange<E>
where E: Send,

§

impl<E, M> Send for Capture<E, M>
where E: Send, M: Send,

§

impl<F> Send for wasmtime_environ::__core::fmt::FromFn<F>
where F: Send,

§

impl<F> Send for PollFn<F>
where F: Send,

§

impl<F> Send for wasmtime_environ::__core::iter::FromFn<F>
where F: Send,

§

impl<F> Send for OnceWith<F>
where F: Send,

§

impl<F> Send for RepeatWith<F>
where F: Send,

§

impl<H> Send for BuildHasherDefault<H>

§

impl<I> Send for FromIter<I>
where I: Send,

§

impl<I> Send for DecodeUtf16<I>
where I: Send,

§

impl<I> Send for Cloned<I>
where I: Send,

§

impl<I> Send for Copied<I>
where I: Send,

§

impl<I> Send for Cycle<I>
where I: Send,

§

impl<I> Send for Enumerate<I>
where I: Send,

§

impl<I> Send for Flatten<I>
where <<I as Iterator>::Item as IntoIterator>::IntoIter: Send, I: Send,

§

impl<I> Send for Fuse<I>
where I: Send,

§

impl<I> Send for Intersperse<I>
where <I as Iterator>::Item: Sized + Send, I: Send,

§

impl<I> Send for Peekable<I>
where I: Send, <I as Iterator>::Item: Send,

§

impl<I> Send for Skip<I>
where I: Send,

§

impl<I> Send for StepBy<I>
where I: Send,

§

impl<I> Send for Take<I>
where I: Send,

§

impl<I, F> Send for FilterMap<I, F>
where I: Send, F: Send,

§

impl<I, F> Send for Inspect<I, F>
where I: Send, F: Send,

§

impl<I, F> Send for 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 IntersperseWith<I, G>
where G: Send, <I as Iterator>::Item: Send, I: Send,

§

impl<I, P> Send for 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 SkipWhile<I, P>
where I: Send, P: Send,

§

impl<I, P> Send for TakeWhile<I, P>
where I: Send, P: Send,

§

impl<I, St, F> Send for Scan<I, St, F>
where I: Send, F: Send, St: Send,

§

impl<I, U, F> Send for FlatMap<I, U, F>
where <U as IntoIterator>::IntoIter: Send, I: Send, F: Send,

§

impl<I, const N: usize> Send for wasmtime_environ::__core::iter::ArrayChunks<I, N>
where I: Send, <I as Iterator>::Item: Send,

§

impl<Idx> Send for wasmtime_environ::__core::ops::Range<Idx>
where Idx: Send,

§

impl<Idx> Send for wasmtime_environ::__core::ops::RangeFrom<Idx>
where Idx: Send,

§

impl<Idx> Send for wasmtime_environ::__core::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<Idx> Send for wasmtime_environ::__core::range::Range<Idx>
where Idx: Send,

§

impl<Idx> Send for wasmtime_environ::__core::range::RangeFrom<Idx>
where Idx: Send,

§

impl<Idx> Send for wasmtime_environ::__core::range::RangeInclusive<Idx>
where Idx: Send,

§

impl<K> Send for EntitySet<K>
where K: Send,

§

impl<K> Send for Keys<K>
where K: Send,

§

impl<K, V> Send for Intern<K, V>
where K: Send, V: Send,

§

impl<K, V> Send for NameMap<K, V>
where K: Send, V: Send,

§

impl<K, V> Send for IndexMap<K, V>
where K: Send, V: Send,

§

impl<K, V> Send for BoxedSlice<K, V>
where K: Send, V: Send,

§

impl<K, V> Send for PrimaryMap<K, V>
where K: Send, V: Send,

§

impl<K, V> Send for SecondaryMap<K, V>
where V: Send, K: Send,

§

impl<K, V> Send for SparseMap<K, V>
where K: Send, V: Send,

§

impl<P> Send for VMComponentOffsets<P>
where P: Send,

§

impl<P> Send for VMOffsets<P>
where P: Send,

§

impl<P> Send for VMOffsetsFields<P>
where P: Send,

§

impl<Ptr> Send for Pin<Ptr>
where Ptr: Send,

§

impl<T> Send for ExportItem<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 Poll<T>
where T: Send,

§

impl<T> Send for wasmtime_environ::component::dfg::CoreExport<T>
where T: Send,

§

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

§

impl<T> Send for wasmtime_environ::component::CoreExport<T>
where T: Send,

§

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

§

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

§

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

§

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

§

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

§

impl<T> Send for 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 Pending<T>

§

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

§

impl<T> Send for Empty<T>

§

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

§

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

§

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

§

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 wasmtime_environ::__core::result::IntoIter<T>
where T: Send,

§

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

§

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

§

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

§

impl<T, A> Send for wasmtime_environ::prelude::Box<T, A>
where A: Send, T: Send + ?Sized,

§

impl<T, A> Send for Vec<T, A>
where A: Send, T: Send,

§

impl<T, E> Send for Result<T, E>
where T: Send, E: 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, const N: usize> Send for wasmtime_environ::__core::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<Y, R> Send for CoroutineState<Y, R>
where Y: Send, R: Send,

§

impl<const N: usize> Send for LaneCount<N>

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

impl<'ctx, R> !Send for FrameIter<'ctx, R>

impl<'ctx, R> !Send for LocationRangeIter<'ctx, R>

impl<'ctx, R> Send for Frame<'ctx, R>
where <R as Reader>::Offset: Send, R: Send,

impl<L> Send for LookupResult<L>

impl<R> Send for Context<R>
where R: Sync + Send, <R as Reader>::Offset: Send,

impl<R> Send for FunctionName<R>
where R: Send,

impl<R> Send for SplitDwarfLoad<R>
where R: Send + Sync,

impl Send for Adler32

impl Send for Error

impl<'msg, 'aad> Send for Payload<'msg, 'aad>

impl Send for Candidate

impl Send for Anchored

impl Send for MatchKind

impl Send for StartKind

impl Send for MatchKind

impl Send for Prefilter

impl Send for StateID

impl Send for Builder

impl Send for DFA

impl Send for Builder

impl Send for NFA

impl Send for Builder

impl Send for NFA

impl Send for Builder

impl Send for Config

impl Send for Searcher

impl Send for AhoCorasick

impl Send for BuildError

impl Send for Match

impl Send for MatchError

impl Send for PatternID

impl Send for Span

impl<'a, 'h> Send for FindIter<'a, 'h>

impl<'a, 'h> Send for FindOverlappingIter<'a, 'h>

impl<'a, 'h, A> Send for FindIter<'a, 'h, A>
where A: Sync,

impl<'a, 'h, A> Send for FindOverlappingIter<'a, 'h, A>
where A: Sync,

impl<'a, A, R> Send for StreamFindIter<'a, A, R>
where R: Send, A: Sync,

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

impl<'h> Send for Input<'h>

impl<'s, 'h> Send for FindIter<'s, 'h>

impl Send for StripBytes

impl Send for StripStr

impl Send for WinconBytes

impl<'s> Send for StripBytesIter<'s>

impl<'s> Send for StripStrIter<'s>

impl<'s> Send for StrippedBytes<'s>

impl<'s> Send for StrippedStr<'s>

impl<'s> Send for WinconBytesIter<'s>

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

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

impl Send for AnsiColor

impl Send for Color

impl Send for EffectIter

impl Send for Effects

impl Send for Reset

impl Send for RgbColor

impl Send for Style

impl Send for Action

impl Send for State

impl Send for AsciiParser

impl Send for Params

impl Send for Utf8Parser

impl<'a> Send for ParamsIter<'a>

impl<C> Send for Parser<C>
where C: Send,

impl Send for Error

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

impl Send for Error

impl<'a> Send for Unstructured<'a>

impl<'a, 'b, ElementType> Send for ArbitraryIter<'a, 'b, ElementType>
where ElementType: Send,

impl<'a, ElementType> Send for ArbitraryTakeRestIter<'a, ElementType>
where ElementType: Send,

impl<A, T> Send for Cache<A, T>
where A: Send, T: Send,

impl<A, T, F> Send for Map<A, T, F>
where A: Send, F: Send,

impl<A, T, F> Send for MapCache<A, T, F>
where F: Send, A: Send, T: Send,

impl<D> Send for AccessConvert<D>
where D: Send,

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

impl<T, S> Send for ArcSwapAny<T, S>
where S: Send, T: Send,

impl<T, S> Send for Guard<T, S>
where <S as InnerStrategy<T>>::Protected: Send,

impl Send for Class

impl Send for Error

impl Send for Explicit

impl Send for Implicit

impl Send for Length

impl Send for Real

impl Send for Boolean

impl Send for Enumerated

impl Send for Null

impl Send for Tag

impl Send for UtcTime

impl<'a> Send for PdvIdentification<'a>

impl<'a> Send for Any<'a>

impl<'a> Send for BitString<'a>

impl<'a> Send for BmpString<'a>

impl<'a> Send for EmbeddedPdv<'a>

impl<'a> Send for GeneralString<'a>

impl<'a> Send for GraphicString<'a>

impl<'a> Send for Header<'a>

impl<'a> Send for Ia5String<'a>

impl<'a> Send for Integer<'a>

impl<'a> Send for NumericString<'a>

impl<'a> Send for ObjectDescriptor<'a>

impl<'a> Send for OctetString<'a>

impl<'a> Send for Oid<'a>

impl<'a> Send for PrintableString<'a>

impl<'a> Send for Sequence<'a>

impl<'a> Send for Set<'a>

impl<'a> Send for TeletexString<'a>

impl<'a> Send for UniversalString<'a>

impl<'a> Send for Utf8String<'a>

impl<'a> Send for VideotexString<'a>

impl<'a> Send for VisibleString<'a>

impl<'a, T, F, E> Send for SequenceIterator<'a, T, F, E>
where T: Send, F: Send, E: Send,

impl<'a, TagKind, T, E> Send for TaggedParser<'a, TagKind, T, E>
where T: Send, TagKind: Send, E: Send,

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

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

impl<T, E, TagKind, const CLASS: u8, const TAG: u32> Send for TaggedValue<T, E, TagKind, CLASS, TAG>
where T: Send, TagKind: Send, E: Send,

impl<TagKind, E> Send for TaggedParserBuilder<TagKind, E>
where TagKind: Send, E: Send,

impl Send for RecvError

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

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

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

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

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

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

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

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

impl Send for Level

impl<R> Send for GzipDecoder<R>
where R: Send,

impl<R> Send for GzipEncoder<R>
where R: Send,

impl<W> Send for GzipDecoder<W>
where W: Send,

impl<W> Send for GzipEncoder<W>
where W: Send,

impl Send for AcquireArc

impl Send for Barrier

impl Send for Semaphore

impl<'a> Send for Acquire<'a>

impl<'a> Send for BarrierWait<'a>

impl<'a> Send for SemaphoreGuard<'a>

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

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

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

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

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

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

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

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

impl Send for ShouldFlush

impl Send for State

impl Send for ClientError

impl Send for Event

impl Send for Protocol

impl Send for ServerError

impl Send for AckPolicy

impl Send for Operation

impl Send for AckKind

impl Send for Compression

impl Send for StorageType

impl Send for Client

impl Send for DrainError

impl Send for Request

impl Send for Statistics

impl Send for HeaderMap

impl Send for HeaderName

impl Send for HeaderValue

impl Send for Account

impl Send for Limits

impl Send for Requests

impl Send for Tier

impl Send for Batch

impl Send for BatchConfig

impl Send for Config

impl Send for Ordered

impl Send for Sequence

impl Send for Stream

impl Send for Config

impl Send for Messages

impl Send for Ordered

impl Send for Config

impl Send for Info

impl Send for Context

impl Send for Publish

impl Send for StreamNames

impl Send for Streams

impl Send for Status

impl Send for Config

impl Send for Entry

impl Send for History

impl Send for Keys

impl Send for Store

impl Send for Watch

impl Send for Acker

impl Send for Message

impl Send for Config

impl Send for List

impl Send for Object

impl Send for ObjectInfo

impl Send for ObjectLink

impl Send for ObjectStore

impl Send for Watch

impl Send for PublishAck

impl Send for ClusterInfo

impl Send for Config

impl Send for Consumers

impl Send for External

impl Send for Info

impl Send for No

impl Send for PagedInfo

impl Send for PeerInfo

impl Send for Placement

impl Send for RawMessage

impl Send for Republish

impl Send for Source

impl Send for SourceInfo

impl Send for State

impl Send for Yes

impl Send for Error

impl Send for ErrorCode

impl Send for Message

impl Send for StatusCode

impl Send for Auth

impl Send for AuthError

impl Send for ConnectInfo

impl Send for ServerAddr

impl Send for ServerInfo

impl Send for Subscriber

impl Send for Subject

impl<'a> Send for BatchBuilder<'a>

impl<'a> Send for FetchBuilder<'a>

impl<'a> Send for StreamBuilder<'a>

impl<'a> Send for Info<'a>

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

impl<Kind> Send for Error<Kind>
where Kind: Send,

impl<SEQUENCE, KEEP> Send for Purge<SEQUENCE, KEEP>
where SEQUENCE: Send, KEEP: Send,

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

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

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

impl Send for ImdsError

impl Send for Builder

impl Send for Builder

impl Send for Builder

impl Send for Builder

impl Send for Builder

impl Send for Builder

impl Send for BuildError

impl Send for IoError

impl Send for TokenError

impl Send for Unexpected

impl Send for Builder

impl Send for Builder

impl Send for Builder

impl Send for Client

impl Send for Builder

impl Send for Builder

impl Send for Builder

impl<'a> Send for ProvideRegion<'a>

impl Send for TokenError

impl Send for AccountId

impl Send for Unhandled

impl Send for Credentials

impl<'a> Send for ProvideCredentials<'a>

impl<'a> Send for ProvideToken<'a>

impl<'c, T> Send for ProvideCredentialsFn<'c, T>
where T: Send + Sync,

impl<'c, T> Send for ProvideTokenFn<'c, T>
where T: Send + Sync,

impl Send for Os

impl Send for SigV4Signer

impl Send for Builder

impl Send for Properties

impl Send for Property

impl Send for Profile

impl Send for SsoSession

impl Send for File

impl Send for Source

impl Send for ApiMetadata

impl<'a> Send for EnvConfigSource<'a>

impl<'a> Send for EnvConfigValue<'a>

impl<E> Send for EnvConfigError<E>
where E: Send,

impl<E> Send for AwsErrorCodeClassifier<E>
where E: Send,

impl<E> Send for AwsErrorCodeClassifierBuilder<E>
where E: Send,

impl<InnerBody> Send for AwsChunkedBody<InnerBody>
where InnerBody: Send,

impl Send for Error

impl Send for BucketType

impl Send for Event

impl Send for JsonType

impl Send for MfaDelete

impl Send for Payer

impl Send for Permission

impl Send for Protocol

impl Send for QuoteFields

impl Send for SessionMode

impl Send for Tier

impl Send for Type

impl Send for Params

impl Send for Builder

impl Send for CopyObject

impl Send for GetObject

impl Send for HeadBucket

impl Send for HeadObject

impl Send for ListBuckets

impl Send for ListObjects

impl Send for ListParts

impl Send for PutObject

impl Send for UploadPart

impl Send for Client

impl Send for Config

impl Send for PartBuilder

impl Send for TagBuilder

impl Send for NoSuchKey

impl Send for NotFound

impl Send for Bucket

impl Send for BucketInfo

impl Send for Checksum

impl Send for Condition

impl Send for CorsRule

impl Send for CsvInput

impl Send for CsvOutput

impl Send for Delete

impl Send for Destination

impl Send for Encryption

impl Send for EndEvent

impl Send for Error

impl Send for FilterRule

impl Send for Grant

impl Send for Grantee

impl Send for Initiator

impl Send for JsonInput

impl Send for JsonOutput

impl Send for Metrics

impl Send for Object

impl Send for ObjectPart

impl Send for Owner

impl Send for Part

impl Send for Progress

impl Send for Redirect

impl Send for RoutingRule

impl Send for S3KeyFilter

impl Send for S3Location

impl Send for ScanRange

impl Send for Ssekms

impl Send for Sses3

impl Send for Stats

impl Send for StatsEvent

impl Send for Tag

impl Send for Tagging

impl Send for TargetGrant

impl Send for Tiering

impl Send for Transition

impl<T, E> Send for EventReceiver<T, E>
where E: Send,

impl<T, E, B> Send for CustomizableOperation<T, E, B>
where B: Send, T: Send, E: Send,

impl Send for Error

impl Send for Params

impl Send for Builder

impl Send for AssumeRole

impl Send for AssumeRoot

impl Send for Client

impl Send for Config

impl Send for TagBuilder

impl Send for Credentials

impl Send for Tag

impl<T, E, B> Send for CustomizableOperation<T, E, B>
where B: Send, T: Send, E: Send,

impl Send for BuildError

impl<'a> Send for SignableBody<'a>

impl<'a> Send for SigningParams<'a>

impl<'a> Send for SignableRequest<'a>

impl<'a, S> Send for Builder<'a, S>
where S: Send,

impl<'a, S> Send for SigningParams<'a, S>
where S: Send,

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

impl Send for OnlyReady

impl Send for Never

impl Send for Sleep

impl Send for TokioSleep

impl<Item> Send for FnStream<Item>
where Item: Send,

impl<Item> Send for PaginationStream<Item>
where Item: Send,

impl<Page, Err> Send for TryFlatMap<Page, Err>
where Page: Send, Err: Send,

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

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

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

impl<T, F> Send for NowOrLater<T, F>
where F: Send, T: Send,

impl<T, S> Send for Timeout<T, S>
where T: Send, S: Send,

impl Send for Error

impl<InnerBody> Send for ChecksumBody<InnerBody>
where InnerBody: Send,

impl<InnerBody> Send for ChecksumBody<InnerBody>
where InnerBody: Send,

impl Send for Error

impl Send for NoOpSigner

impl<'a> Send for ResponseHeaders<'a>

impl<T, E> Send for UnmarshalledMessage<T, E>
where T: Send, E: Send,

impl Send for ParseError

impl<'a> Send for Writer<'a>

impl Send for EscapeError

impl Send for Offset

impl<'a> Send for Token<'a>

impl<'a> Send for JsonTokenIterator<'a>

impl<'a> Send for EscapedStr<'a>

impl<'a> Send for JsonArrayWriter<'a>

impl<'a> Send for JsonObjectWriter<'a>

impl<'a> Send for JsonValueWriter<'a>

impl Send for ErrorKind

impl Send for Meter

impl Send for Attributes

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

impl<'a, T, M> Send for AsyncInstrumentBuilder<'a, T, M>
where T: Send,

impl<'a> Send for QueryListWriter<'a>

impl<'a> Send for QueryMapWriter<'a>

impl<'a> Send for QueryValueWriter<'a>

impl<'a> Send for QueryWriter<'a>

impl Send for StopPoint

impl Send for Throughput

impl Send for TokenBucket

impl<'a> Send for Resolver<'a>

impl<AcceptorFn, OperationFn> Send for WaiterOrchestrator<AcceptorFn, OperationFn>
where AcceptorFn: Send, OperationFn: Send,

impl<AcceptorFn, OperationFn> Send for WaiterOrchestratorBuilder<AcceptorFn, OperationFn>
where AcceptorFn: Send, OperationFn: Send,

impl<B> Send for MinimumThroughputDownloadBody<B>
where B: Send,

impl<E> Send for ModeledAsRetryableClassifier<E>
where E: Send,

impl<E> Send for TransientErrorClassifier<E>
where E: Send,

impl<F> Send for MutateRequestInterceptor<F>
where F: Send,

impl<F, E> Send for MapRequestInterceptor<F, E>
where F: Send, E: Send,

impl<I, O, E> Send for Operation<I, O, E>
where I: Send, O: Send, E: Send,

impl<I, O, E> Send for OperationBuilder<I, O, E>
where I: Send, O: Send, E: Send,

impl<K, V> Send for StaticPartitionMap<K, V>
where K: Send, V: Send,

impl<T, E> Send for ExpiringCache<T, E>
where E: Send, T: Send + Sync,

impl Send for RetryAction

impl Send for RetryReason

impl Send for Order

impl Send for Login

impl Send for Token

impl Send for BuildError

impl Send for Builder

impl Send for Identity

impl Send for Error

impl Send for Input

impl Send for Output

impl Send for Metadata

impl Send for AlwaysRetry

impl Send for BuildError

impl Send for Builder

impl Send for HeaderValue

impl Send for Headers

impl Send for HttpError

impl Send for StatusCode

impl<'a> Send for AuthSchemeOptionsFuture<'a>

impl<'a> Send for DnsFuture<'a>

impl<'a> Send for EndpointFuture<'a>

impl<'a> Send for IdentityFuture<'a>

impl<'a> Send for HeadersIter<'a>

impl<'a, I, O, E> Send for AfterDeserializationInterceptorContextRef<'a, I, O, E>
where I: Sync, O: Sync, E: Sync,

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

impl<'a, I, O, E> Send for BeforeDeserializationInterceptorContextRef<'a, I, O, E>
where I: Sync, O: Sync, E: Sync,

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

impl<'a, I, O, E> Send for BeforeSerializationInterceptorContextRef<'a, I, O, E>
where I: Sync, O: Sync, E: Sync,

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

impl<'a, I, O, E> Send for BeforeTransmitInterceptorContextRef<'a, I, O, E>
where I: Sync, O: Sync, E: Sync,

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

impl<'a, I, O, E> Send for FinalizerInterceptorContextRef<'a, I, O, E>
where I: Sync, O: Sync, E: Sync,

impl<B> Send for Request<B>
where B: Send,

impl<B> Send for RequestParts<B>
where B: Send,

impl<B> Send for Response<B>
where B: Send,

impl<E> Send for OrchestratorError<E>
where E: Send,

impl<E> Send for OperationFailed<E>
where E: Send,

impl<E, R> Send for SdkError<E, R>
where R: Send, E: Send,

impl<E, R> Send for ServiceErrorBuilder<E, R>
where E: Send, R: Send,

impl<E, R> Send for ServiceError<E, R>
where E: Send, R: Send,

impl<I, O, E> Send for InterceptorContext<I, O, E>
where I: Send, O: Send, E: Send,

impl<O, E> Send for WaiterError<O, E>
where O: Send, E: Send,

impl<O, E> Send for FailureState<O, E>
where O: Send, E: Send,

impl<O, E> Send for FinalPoll<O, E>
where O: Send, E: Send,

impl<R> Send for ResponseErrorBuilder<R>
where R: Send,

impl<R> Send for ResponseError<R>
where R: Send,

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

impl Send for Length

impl Send for Format

impl Send for Document

impl Send for Number

impl Send for HeaderValue

impl Send for RawMessage

impl Send for ErrorKind

impl Send for RetryKind

impl Send for RetryMode

impl Send for DecodeError

impl Send for SdkBody

impl Send for Error

impl Send for ByteStream

impl Send for FsBuilder

impl Send for ConfigBag

impl Send for FrozenLayer

impl Send for Layer

impl Send for DateTime

impl Send for Builder

impl Send for Endpoint

impl Send for Builder

impl Send for BuildError

impl Send for Header

impl Send for Message

impl Send for Encoder

impl Send for RetryConfig

impl Send for StrBytes

impl Send for Blob

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

impl<'a, U> Send for AppendItemIter<'a, U>
where U: Sync + Send,

impl<E> Send for DisplayErrorContext<E>
where E: Send,

impl<U> Send for StoreAppend<U>
where U: Send,

impl<U> Send for StoreReplace<U>
where U: Send,

impl<'a> Send for Attr<'a>

impl<'a> Send for Document<'a>

impl<'a> Send for Name<'a>

impl<'a> Send for StartEl<'a>

impl<'a> Send for XmlWriter<'a>

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

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

impl<'inp> Send for XmlToken<'inp>

impl<'inp, 'a> Send for ScopedDecoder<'inp, 'a>

impl Send for OsFamily

impl Send for AppName

impl Send for EndpointUrl

impl Send for UseFips

impl Send for Origin

impl Send for Env

impl Send for Fs

impl Send for Region

impl Send for Builder

impl Send for SdkConfig

impl Send for Error

impl Send for SigningName

impl<'a> Send for Builder<'a>

impl<'a> Send for ServiceConfigKey<'a>

impl Send for ErrorKind

impl Send for NestedPath

impl Send for OriginalUri

impl Send for RawForm

impl Send for RawQuery

impl Send for Next

impl Send for Event

impl Send for KeepAlive

impl Send for NoContent

impl Send for Redirect

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

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

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

impl<B, S> Send for RouterIntoService<B, S>
where B: Send,

impl<B, T, E, S> Send for ResponseFuture<B, T, E, S>
where <T as Service<Request<B>>>::Future: Send, T: Send,

impl<E> Send for RouteFuture<E>

impl<E> Send for Route<E>

impl<E, S> Send for FromExtractorLayer<E, S>
where S: Send,

impl<F> Send for IntoServiceFuture<F>
where F: Send,

impl<F, S, I, T> Send for FromFn<F, S, I, T>
where F: Send, I: Send, S: Send,

impl<F, S, I, T> Send for MapRequest<F, S, I, T>
where F: Send, I: Send, S: Send,

impl<F, S, I, T> Send for 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 MapRequestLayer<F, S, T>
where F: Send, S: Send,

impl<F, S, T> Send for MapResponseLayer<F, S, T>
where F: Send, S: Send,

impl<F, T> Send for HandleErrorLayer<F, T>
where F: Send,

impl<H, T, S> Send for HandlerService<H, T, S>
where H: Send, S: 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<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, C> Send for IntoMakeServiceWithConnectInfo<S, C>
where S: Send,

impl<S, C> Send for ResponseFuture<S, C>
where S: Send, C: Send,

impl<S, E> Send for MethodRouter<S, E>

impl<S, F, T> Send for HandleError<S, F, T>
where S: Send, F: Send,

impl<S, T> Send for AddExtension<S, T>
where S: Send, T: Send,

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

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

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

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

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

impl<T, E, S> Send for FromExtractor<T, E, S>
where T: Send, S: Send,

impl Send for Body

impl Send for InvalidUtf8

impl Send for Error

impl<I> Send for AppendHeaders<I>
where I: Send,

impl<K, V> Send for TryIntoHeaderError<K, V>
where K: Send, V: Send,

impl Send for Host

impl<E, R> Send for WithRejection<E, R>
where E: Send, R: Send,

impl<E1, E2> Send for Either<E1, E2>
where E1: Send, E2: Send,

impl<E1, E2, E3> Send for Either3<E1, E2, E3>
where E1: Send, E2: Send, E3: Send,

impl<E1, E2, E3, E4> Send for Either4<E1, E2, E3, E4>
where E1: Send, E2: Send, E3: Send, E4: Send,

impl<E1, E2, E3, E4, E5> Send for Either5<E1, E2, E3, E4, E5>
where E1: Send, E2: Send, E3: Send, E4: Send, E5: Send,

impl<E1, E2, E3, E4, E5, E6> Send for Either6<E1, E2, E3, E4, E5, E6>
where E1: Send, E2: Send, E3: Send, E4: Send, E5: Send, E6: Send,

impl<E1, E2, E3, E4, E5, E6, E7> Send for Either7<E1, E2, E3, E4, E5, E6, E7>
where E1: Send, E2: Send, E3: Send, E4: Send, E5: Send, E6: Send, E7: Send,

impl<E1, E2, E3, E4, E5, E6, E7, E8> Send for Either8<E1, E2, E3, E4, E5, E6, E7, E8>
where E1: Send, E2: Send, E3: Send, E4: Send, E5: Send, E6: Send, E7: Send, E8: Send,

impl<H, T, S> Send for IntoHandler<H, T, S>
where H: Send,

impl<L, R, Lt, Rt, S> Send for Or<L, R, Lt, Rt, S>
where L: Send, R: Send,

impl<S> Send for Resource<S>

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

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

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

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

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

impl Send for Handle

impl<A> Send for Server<A>
where A: Send,

impl<A> Send for RustlsAcceptor<A>
where A: Send,

impl<F, I, S> Send for RustlsAcceptorFuture<F, I, S>
where F: Send, S: Send, I: Send,

impl Send for Body

impl Send for LeaseAction

impl Send for LeaseState

impl Send for LeaseStatus

impl Send for ErrorKind

impl Send for LroStatus

impl Send for FinalState

impl Send for Range

impl Send for AccessToken

impl Send for Secret

impl Send for Error

impl Send for HttpError

impl Send for HeaderName

impl Send for HeaderValue

impl Send for Headers

impl Send for Accept

impl Send for ActivityId

impl Send for App

impl Send for ContentType

impl Send for Delimiter

impl Send for IfTags

impl Send for LeaseId

impl Send for MaxResults

impl Send for Metadata

impl Send for NextMarker

impl Send for Prefix

impl Send for Timeout

impl Send for User

impl Send for UserAgent

impl Send for Version

impl Send for Sleep

impl Send for BytesStream

impl Send for Context

impl Send for Etag

impl Send for Pipeline

impl Send for Request

impl Send for Response

impl<T, E> Send for Pageable<T, E>

impl Send for ServiceType

impl Send for SasProtocol

impl Send for SasKey

impl Send for CopyId

impl Send for IPRange

impl<'a> Send for ConnectionString<'a>

impl<'a> Send for ConnectionStringBuilder<'a>

impl Send for BlobType

impl Send for CopyStatus

impl Send for BlobItem

impl Send for AccessTier

impl Send for BlobExpiry

impl Send for Hash

impl Send for Blob

impl Send for BlockList

impl Send for BlobPrefix

impl Send for Blobs

impl Send for Container

impl Send for BA512Range

impl Send for BlobClient

impl Send for BlockId

impl Send for CPKInfo

impl Send for Snapshot

impl Send for Tags

impl Send for VersionId

impl Send for Blob

impl Send for BlobType

impl Send for AccessTier

impl Send for CopyStatus

impl Send for ErrorCode

impl Send for LeaseState

impl Send for LeaseStatus

impl Send for QueryType

impl Send for Status

impl Send for QueryType

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Client

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Client

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Client

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Client

impl Send for Response

impl Send for Schema

impl Send for TagSet

impl Send for Blobs

impl Send for Containers

impl Send for Cors

impl Send for ArrowField

impl Send for BlobName

impl Send for BlobPrefix

impl Send for BlobTag

impl Send for BlobTags

impl Send for Block

impl Send for BlockList

impl Send for ClearRange

impl Send for CorsRule

impl Send for KeyInfo

impl Send for Logging

impl Send for Metrics

impl Send for PageList

impl Send for PageRange

impl Send for QueryFormat

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Client

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Response

impl Send for Client

impl Send for Response

impl Send for Client

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<'a> Send for Headers<'a>

impl<B, T, E, Ctx, F, SF, RF, NF> Send for BlockingRetryWithContext<B, T, E, Ctx, F, SF, RF, NF>
where RF: Send, NF: Send, F: Send, SF: Send, Ctx: Send,

impl<B, T, E, Ctx, Fut, FutureFn, SF, RF, NF> Send for RetryWithContext<B, T, E, Ctx, Fut, FutureFn, SF, RF, NF>
where RF: Send, NF: Send, FutureFn: Send, SF: Send, Fut: Send, Ctx: Send, <SF as MaybeSleeper>::Sleep: Send,

impl<B, T, E, F, SF, RF, NF> Send for BlockingRetry<B, T, E, F, SF, RF, NF>
where RF: Send, NF: Send, F: Send, SF: Send,

impl<B, T, E, Fut, FutureFn, SF, RF, NF, AF> Send for Retry<B, T, E, Fut, FutureFn, SF, RF, NF, AF>
where FutureFn: Send, RF: Send, NF: Send, SF: Send, AF: Send, Fut: Send, <SF as MaybeSleeper>::Sleep: Send,

impl Send for DecodeError

impl Send for Alphabet

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

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 Send for Base64

impl Send for Error

impl Send for Error

impl Send for LineEnding

impl Send for Base64

impl Send for Base64Crypt

impl Send for Base64Url

impl<'i, E> Send for Decoder<'i, E>

impl<'o, E> Send for Encoder<'o, E>

impl Send for BigDecimal

impl Send for Context

impl<'a> Send for BigDecimalRef<'a>

impl<'a, B> Send for Blocks<'a, B>
where B: Sync,

impl<'a, B> Send for Iter<'a, B>
where B: Sync,

impl<B> Send for BitVec<B>
where B: Send,

impl<B> Send for IntoIter<B>
where B: Send,

impl Send for ParseError

impl<B> Send for 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 Send for Eager

impl Send for Error

impl Send for Lazy

impl<BlockSize, Kind> Send for BlockBuffer<BlockSize, Kind>
where Kind: Send,

impl Send for AllocErr

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

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

impl<E> Send for AllocOrInitError<E>
where E: Send,

impl Send for BigEndian

impl Send for UninitSlice

impl Send for TryGetError

impl<B> Send for Reader<B>
where B: Send,

impl<B> Send for Writer<B>
where B: Send,

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

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

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

impl<T, U> Send for Chain<T, U>
where T: Send, U: Send,

impl Send for Direction

impl<'a, B> Send for SegmentedSlice<'a, B>
where B: Send,

impl<B> Send for SegmentedBuf<B>
where B: Send,

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

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

impl<S, F> Send for BytesIter<S, F>
where F: Send, S: Send,

impl Send for Blocking

impl Send for TcpBinder

impl Send for UdpBinder

impl Send for AccessType

impl Send for AccessModes

impl Send for DirBuilder

impl Send for DirEntry

impl Send for DirOptions

impl Send for FileType

impl Send for Metadata

impl Send for OpenOptions

impl Send for Permissions

impl Send for ReadDir

impl Send for Pool

impl Send for Instant

impl Send for SystemClock

impl Send for SystemTime

impl !Send for CapRng

impl Send for OsRng

impl Send for Dir

impl Send for DirEntry

impl Send for File

impl Send for ReadDir

impl Send for Pool

impl Send for TcpListener

impl Send for TcpStream

impl Send for UdpSocket

impl Send for UnixStream

impl<'a> Send for Incoming<'a>

impl<'a> Send for Incoming<'a>

impl Send for Timezone

impl Send for Month

impl Send for Weekday

impl Send for Colons

impl Send for Fixed

impl Send for Numeric

impl Send for Pad

impl Send for ParseError

impl Send for Parsed

impl Send for IsoWeek

impl Send for NaiveWeek

impl Send for Days

impl Send for FixedOffset

impl Send for Local

impl Send for Months

impl Send for NaiveDate

impl Send for NaiveTime

impl Send for OutOfRange

impl Send for TimeDelta

impl Send for Utc

impl Send for WeekdaySet

impl<'a> Send for Item<'a>

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

impl<I> Send for DelayedFormat<I>
where I: Send,

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

impl<Tz> Send for DateTime<Tz>
where <Tz as TimeZone>::Offset: Send,

impl Send for AnyIpCidr

impl Send for Family

impl Send for IpCidr

impl Send for IpInet

impl Send for IpInetPair

impl Send for Ipv4Cidr

impl Send for Ipv4Inet

impl Send for Ipv6Cidr

impl Send for Ipv6Inet

impl<A> Send for InetAddressIterator<A>
where <A as Address>::InetPair: Send,

impl<A> Send for InetIterator<A>
where <A as Address>::InetPair: Send,

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

impl Send for ArgAction

impl Send for ValueHint

impl Send for ColorChoice

impl Send for ContextKind

impl Send for ErrorKind

impl Send for ValueSource

impl Send for Arg

impl Send for ArgGroup

impl Send for Command

impl Send for OsStr

impl Send for Str

impl Send for StyledStr

impl Send for ValueParser

impl Send for ValueRange

impl Send for Styles

impl Send for ArgMatches

impl Send for Id

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

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

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

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

impl<E> Send for EnumValueParser<E>

impl<F> Send for Error<F>
where F: 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<T> Send for Resettable<T>
where T: Send,

impl<T> Send for RangedI64ValueParser<T>

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

impl<T> Send for Values<T>

impl Send for ArgCursor

impl Send for RawArgs

impl<'s> Send for ParsedArg<'s>

impl<'s> Send for ShortFlags<'s>

impl Send for Attributes

impl Send for Data

impl Send for Error

impl Send for SpecVersion

impl Send for Encoding

impl Send for Error

impl Send for Attributes

impl Send for Attributes

impl Send for Event

impl<'a> Send for AttributeValue<'a>

impl Send for PushResult

impl<'a> Send for CobsDecoder<'a>

impl<'a> Send for CobsEncoder<'a>

impl Send for ColorChoice

impl Send for TakeRange

impl Send for Error

impl Send for Static

impl Send for Buffer

impl Send for Bufferless

impl<'a, Input, P, S, M> Send for Iter<'a, Input, P, S, M>
where P: Send, S: Send, M: Send, Input: Send, <Input as StreamOnce>::Error: Send,

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

impl<A> Send for PartialState1<A>
where A: Send,

impl<A, B> Send for PartialState2<A, B>
where A: Send, B: Send,

impl<A, B, C> Send for PartialState3<A, B, C>
where A: Send, B: Send, C: Send,

impl<A, B, C, D> Send for PartialState4<A, B, C, D>
where A: Send, B: Send, C: Send, D: Send,

impl<A, B, C, D, E> Send for PartialState5<A, B, C, D, E>
where A: Send, B: Send, C: Send, D: Send, E: Send,

impl<A, B, C, D, E, F> Send for PartialState6<A, B, C, D, E, F>
where A: Send, B: Send, C: Send, D: Send, E: Send, F: Send,

impl<A, B, C, D, E, F, G> Send for PartialState7<A, B, C, D, E, F, G>
where A: Send, B: Send, C: Send, D: Send, E: Send, F: Send, G: Send,

impl<A, B, C, D, E, F, G, H> Send for PartialState8<A, B, C, D, E, F, G, H>
where A: Send, B: Send, C: Send, D: Send, E: Send, F: Send, G: Send, H: Send,

impl<A, B, C, D, E, F, G, H, I> Send for PartialState9<A, B, C, D, E, F, G, H, I>
where A: Send, B: Send, C: Send, D: Send, E: Send, F: Send, G: Send, H: Send, I: Send,

impl<A, B, C, D, E, F, G, H, I, J> Send for PartialState10<A, B, C, D, E, F, G, H, I, J>
where A: Send, B: Send, C: Send, D: Send, E: Send, F: Send, G: Send, H: Send, I: Send, J: Send,

impl<A, B, C, D, E, F, G, H, I, J, K> Send for PartialState11<A, B, C, D, E, F, G, H, I, J, K>
where A: Send, B: Send, C: Send, D: Send, E: Send, F: Send, G: Send, H: Send, I: Send, J: Send, K: Send,

impl<A, B, C, D, E, F, G, H, I, J, K, L> Send for PartialState12<A, B, C, D, E, F, G, H, I, J, K, L>
where A: Send, B: Send, C: Send, D: Send, E: Send, F: Send, G: Send, H: Send, I: Send, J: Send, K: Send, L: Send,

impl<A, B, C, D, E, F, G, H, I, J, K, L, M> Send for PartialState13<A, B, C, D, E, F, G, H, I, J, K, L, M>
where A: Send, B: Send, C: Send, D: Send, E: Send, F: Send, G: Send, H: Send, I: Send, J: Send, K: Send, L: Send, M: Send,

impl<A, B, C, D, E, F, G, H, I, J, K, L, M, N> Send for PartialState14<A, B, C, D, E, F, G, H, I, J, K, L, M, N>
where A: Send, B: Send, C: Send, D: Send, E: Send, F: Send, G: Send, H: Send, I: Send, J: Send, K: Send, L: Send, M: Send, N: Send,

impl<A, B, C, D, E, F, G, H, I, J, K, L, M, N, P> Send for PartialState15<A, B, C, D, E, F, G, H, I, J, K, L, M, N, P>
where A: Send, B: Send, C: Send, D: Send, E: Send, F: Send, G: Send, H: Send, I: Send, J: Send, K: Send, L: Send, M: Send, N: Send, P: Send,

impl<A, B, C, D, E, F, G, H, I, J, K, L, M, N, P, Q> Send for PartialState16<A, B, C, D, E, F, G, H, I, J, K, L, M, N, P, Q>
where A: Send, B: Send, C: Send, D: Send, E: Send, F: Send, G: Send, H: Send, I: Send, J: Send, K: Send, L: Send, M: Send, N: Send, P: Send, Q: Send,

impl<A, B, C, D, E, F, G, H, I, J, K, L, M, N, P, Q, R> Send for PartialState17<A, B, C, D, E, F, G, H, I, J, K, L, M, N, P, Q, R>
where A: Send, B: Send, C: Send, D: Send, E: Send, F: Send, G: Send, H: Send, I: Send, J: Send, K: Send, L: Send, M: Send, N: Send, P: Send, Q: Send, R: Send,

impl<A, B, C, D, E, F, G, H, I, J, K, L, M, N, P, Q, R, S> Send for PartialState18<A, B, C, D, E, F, G, H, I, J, K, L, M, N, P, Q, R, S>
where A: Send, B: Send, C: Send, D: Send, E: Send, F: Send, G: Send, H: Send, I: Send, J: Send, K: Send, L: Send, M: Send, N: Send, P: Send, Q: Send, R: Send, S: Send,

impl<A, B, C, D, E, F, G, H, I, J, K, L, M, N, P, Q, R, S, T> Send for PartialState19<A, B, C, D, E, F, G, H, I, J, K, L, M, N, P, Q, R, S, T>
where A: Send, B: Send, C: Send, D: Send, E: Send, F: Send, G: Send, H: Send, I: Send, J: Send, K: Send, L: Send, M: Send, N: Send, P: Send, Q: Send, R: Send, S: Send, T: Send,

impl<A, B, C, D, E, F, G, H, I, J, K, L, M, N, P, Q, R, S, T, U> Send for PartialState20<A, B, C, D, E, F, G, H, I, J, K, L, M, N, P, Q, R, S, T, U>
where A: Send, B: Send, C: Send, D: Send, E: Send, F: Send, G: Send, H: Send, I: Send, J: Send, K: Send, L: Send, M: Send, N: Send, P: Send, Q: Send, R: Send, S: Send, T: Send, U: Send,

impl<C, E, T, Input> Send for Tokens<C, E, T, Input>
where C: Send, E: Send, T: Send, Input: Send,

impl<C, T, Input> Send for TokensCmp<C, T, Input>
where C: Send, T: Send, Input: Send,

impl<E> Send for Tracked<E>
where E: Send,

impl<E, Input, T> Send for EnvParser<E, Input, T>
where E: Send,

impl<E, P> Send for Error<E, P>
where E: Send, P: Send,

impl<F> Send for Format<F>
where F: Send,

impl<F> Send for PollFn<F>
where F: Send,

impl<F, I, P> Send for Iterate<F, I, P>
where P: Send, I: Send,

impl<F, Input> Send for TakeFn<F, Input>
where F: Send,

impl<F, Input, O, S> Send for Opaque<F, Input, O, S>
where F: Send,

impl<F, Input, P> Send for Count<F, Input, P>
where <Input as StreamOnce>::Error: Sized, P: Send,

impl<F, P> Send for Recognize<F, P>
where P: Send,

impl<F, P> Send for CountMinMax<F, P>
where P: Send,

impl<F, P> Send for Many<F, P>
where P: Send, F: Send,

impl<F, P> Send for Many1<F, P>
where P: Send,

impl<F, P> Send for TakeUntil<F, P>
where P: Send,

impl<F, P, E> Send for RepeatUntil<F, P, E>
where P: Send, E: Send,

impl<F, P, S> Send for SepBy<F, P, S>
where P: Send, S: Send,

impl<F, P, S> Send for SepBy1<F, P, S>
where P: Send, S: Send,

impl<F, P, S> Send for SepEndBy<F, P, S>
where P: Send, S: Send,

impl<F, P, S> Send for SepEndBy1<F, P, S>
where P: Send, S: Send,

impl<I, T, E> Send for Unexpected<I, T, E>
where E: Send,

impl<Input> Send for TakeUntilByte<Input>
where <Input as StreamOnce>::Error: Sized,

impl<Input> Send for TakeUntilByte2<Input>
where <Input as StreamOnce>::Error: Sized,

impl<Input> Send for TakeUntilByte3<Input>
where <Input as StreamOnce>::Error: Sized,

impl<Input> Send for Digit<Input>
where <Input as StreamOnce>::Error: Sized,

impl<Input> Send for Range<Input>
where <Input as StreamOnce>::Range: Send,

impl<Input> Send for Take<Input>

impl<Input> Send for TakeUntilRange<Input>
where <Input as StreamOnce>::Range: Send,

impl<Input> Send for Any<Input>

impl<Input> Send for Eof<Input>
where Input: Send,

impl<Input> Send for Position<Input>
where Input: Send,

impl<Input> Send for Token<Input>
where <Input as StreamOnce>::Token: Send, Input: Send,

impl<Input> Send for Stream<Input>
where Input: Send, <Input as StreamOnce>::Token: Send, <Input as StreamOnce>::Position: Send,

impl<Input> Send for IteratorStream<Input>
where Input: Send,

impl<Input, F> Send for FnParser<Input, F>
where F: Send,

impl<Input, F> Send for TakeWhile<Input, F>
where F: Send,

impl<Input, F> Send for TakeWhile1<Input, F>
where F: Send,

impl<Input, F> Send for Produce<Input, F>
where F: Send,

impl<Input, L, R, P> Send for Between<Input, L, R, P>
where <Input as StreamOnce>::Error: Sized, L: Send, R: Send, P: Send,

impl<Input, O, P> Send for FromStr<Input, O, P>
where <Input as StreamOnce>::Error: Sized, P: Send,

impl<Input, P> Send for Recognize<Input, P>
where <Input as StreamOnce>::Error: Sized, P: Send,

impl<Input, P> Send for SkipCount<Input, P>
where <Input as StreamOnce>::Error: Sized, P: Send,

impl<Input, P> Send for SkipCountMinMax<Input, P>
where <Input as StreamOnce>::Error: Sized, P: Send,

impl<Input, P> Send for SkipMany<Input, P>
where <Input as StreamOnce>::Error: Sized, P: Send,

impl<Input, P> Send for SkipMany1<Input, P>
where <Input as StreamOnce>::Error: Sized, P: Send,

impl<Input, P> Send for SkipUntil<Input, P>
where <Input as StreamOnce>::Error: Sized, P: Send,

impl<Input, P> Send for Satisfy<Input, P>
where P: Send, Input: Send,

impl<Input, P> Send for SatisfyMap<Input, P>
where P: Send, Input: Send,

impl<Input, P, E> Send for SkipRepeatUntil<Input, P, E>
where <Input as StreamOnce>::Error: Sized, P: Send, E: Send,

impl<Input, T> Send for Value<Input, T>
where T: Send,

impl<Input, X> Send for Stream<Input, X>
where Input: Send, X: Send,

impl<InputInner, P, C> Send for InputConverter<InputInner, P, C>
where P: Send, C: Send,

impl<L, R> Send for Either<L, R>
where L: Send, R: Send,

impl<P> Send for Choice<P>
where P: Send,

impl<P> Send for Optional<P>
where P: Send,

impl<P> Send for AnyPartialStateParser<P>
where P: Send,

impl<P> Send for AnySendPartialStateParser<P>
where P: Send,

impl<P> Send for AnySendSyncPartialStateParser<P>
where P: Send,

impl<P> Send for Ignore<P>
where P: Send,

impl<P> Send for Lazy<P>
where P: Send,

impl<P> Send for LookAhead<P>
where P: Send,

impl<P> Send for NoPartial<P>
where P: Send,

impl<P> Send for NotFollowedBy<P>
where P: Send,

impl<P> Send for Spanned<P>
where P: Send,

impl<P> Send for Try<P>
where P: Send,

impl<P> Send for Silent<P>
where P: Send,

impl<P> Send for RecognizeWithValue<P>
where P: Send,

impl<P> Send for Span<P>
where P: Send,

impl<P, F> Send for AndThen<P, F>
where P: Send, F: Send,

impl<P, F> Send for FlatMap<P, F>
where P: Send, F: Send,

impl<P, F> Send for Map<P, F>
where P: Send, F: Send,

impl<P, F> Send for MapInput<P, F>
where P: Send, F: Send,

impl<P, F> Send for Then<P, F>
where P: Send, F: Send,

impl<P, F> Send for ThenPartial<P, F>
where P: Send, F: Send,

impl<P, F> Send for ThenRef<P, F>
where P: Send, F: Send,

impl<P, Op> Send for Chainl1<P, Op>
where P: Send, Op: Send,

impl<P, Op> Send for Chainr1<P, Op>
where P: Send, Op: Send,

impl<P, Q, I> Send for Escaped<P, Q, I>
where P: Send, I: Send, Q: Send,

impl<P, R> Send for Factory<P, R>
where P: Send, R: Send,

impl<P, S> Send for Expected<P, S>
where P: Send, S: Send,

impl<P, S> Send for Message<P, S>
where P: Send, S: Send,

impl<P1, P2> Send for Or<P1, P2>
where P1: Send, P2: Send,

impl<P1, P2> Send for Skip<P1, P2>
where P1: Send, P2: Send,

impl<P1, P2> Send for With<P1, P2>
where P2: Send, P1: Send,

impl<R> Send for Range<R>
where R: Send,

impl<R> Send for BufReader<R>
where R: Send,

impl<R> Send for Stream<R>
where R: Send,

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

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

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

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

impl<S, E> Send for Stream<S, E>
where S: Send,

impl<S, P, C> Send for Decoder<S, P, C>
where P: Send, S: Send, C: Send,

impl<S, U> Send for Stream<S, U>
where S: Send, U: Send,

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

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

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

impl<T, E> Send for ParseResult<T, E>
where T: Send, E: Send,

impl<T, Input> Send for NoneOf<T, Input>
where T: Send, Input: Send,

impl<T, Input> Send for OneOf<T, Input>
where T: Send, Input: Send,

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

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

impl<T, R, F> Send for Info<T, R, F>
where T: Send, R: Send, F: Send,

impl<T, R, P> Send for Errors<T, R, P>
where P: Send, T: Send, R: Send,

impl<T, U> Send for EscapedState<T, U>
where T: Send, U: Send,

impl Send for PopError

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

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

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

impl Send for Error

impl<'a> Send for Database<'a>

impl<'a> Send for Names<'a>

impl<'a> Send for Arcs<'a>

impl Send for Extension

impl Send for Scale

impl Send for Size

impl Send for adcb_i

impl Send for adcl_i

impl Send for adcq_i_sxl

impl Send for adcw_i

impl Send for addb_i

impl Send for addl_i

impl Send for addq_i_sxl

impl Send for addw_i

impl Send for andb_i

impl Send for andl_i

impl Send for andq_i_sxl

impl Send for andw_i

impl Send for orb_i

impl Send for orl_i

impl Send for orq_i_sxl

impl Send for orw_i

impl Send for sbbb_i

impl Send for sbbl_i

impl Send for sbbq_i_sxl

impl Send for sbbw_i

impl Send for subb_i

impl Send for subl_i

impl Send for subq_i_sxl

impl Send for subw_i

impl Send for xorb_i

impl Send for xorl_i

impl Send for xorq_i_sxl

impl Send for xorw_i

impl Send for AmodeOffset

impl Send for Constant

impl Send for Imm16

impl Send for Imm32

impl Send for Imm8

impl Send for Label

impl Send for RexFlags

impl Send for Simm16

impl Send for Simm32

impl Send for Simm8

impl Send for TrapCode

impl<R> Send for Amode<R>
where R: Send,

impl<R> Send for adcb_mi<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for adcb_mr<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for adcb_rm<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for adcl_mi<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for adcl_mi_sxb<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for adcl_mr<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for adcl_rm<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for adcq_mi_sxb<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for adcq_mi_sxl<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for adcq_mr<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for adcq_rm<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for adcw_mi<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for adcw_mr<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for adcw_rm<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for addb_mi<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for addb_mr<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for addb_rm<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for addl_mi<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for addl_mi_sxb<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for addl_mr<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for addl_rm<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for addq_mi_sxb<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for addq_mi_sxl<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for addq_mr<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for addq_rm<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for addw_mi<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for addw_mr<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for addw_rm<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for andb_mi<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for andb_mr<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for andb_rm<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for andl_mi<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for andl_mi_sxb<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for andl_mr<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for andl_rm<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for andq_mi_sxb<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for andq_mi_sxl<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for andq_mr<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for andq_rm<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for andw_mi<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for andw_mr<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for andw_rm<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for orb_mi<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for orb_mr<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for orb_rm<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for orl_mi<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for orl_mi_sxb<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for orl_mr<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for orl_rm<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for orpd_a<R>
where <R as Registers>::ReadWriteXmm: Send, <R as Registers>::ReadXmm: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for orq_mi_sxb<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for orq_mi_sxl<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for orq_mr<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for orq_rm<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for orw_mi<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for orw_mr<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for orw_rm<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for sbbb_mi<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for sbbb_mr<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for sbbb_rm<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for sbbl_mi<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for sbbl_mi_sxb<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for sbbl_mr<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for sbbl_rm<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for sbbq_mi_sxb<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for sbbq_mi_sxl<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for sbbq_mr<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for sbbq_rm<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for sbbw_mi<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for sbbw_mr<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for sbbw_rm<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for shldl_mrc<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for shldl_mri<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for shldq_mrc<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for shldq_mri<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for shldw_mrc<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for shldw_mri<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for subb_mi<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for subb_mr<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for subb_rm<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for subl_mi<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for subl_mi_sxb<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for subl_mr<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for subl_rm<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for subq_mi_sxb<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for subq_mi_sxl<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for subq_mr<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for subq_rm<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for subw_mi<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for subw_mr<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for subw_rm<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for xorb_mi<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for xorb_mr<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for xorb_rm<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for xorl_mi<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for xorl_mi_sxb<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for xorl_mr<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for xorl_rm<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for xorq_mi_sxb<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for xorq_mi_sxl<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for xorq_mr<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for xorq_rm<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for xorw_mi<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for xorw_mr<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for xorw_rm<R>
where <R as Registers>::ReadWriteGpr: Send, <R as Registers>::ReadGpr: Send,

impl<R> Send for Gpr<R>
where R: Send,

impl<R> Send for NonRspGpr<R>
where R: Send,

impl<R> Send for Xmm<R>
where R: Send,

impl<R, M> Send for GprMem<R, M>
where R: Send, M: Send,

impl<R, M> Send for XmmMem<R, M>
where R: Send, M: Send,

impl<'a, K> Send for SetIter<'a, K>
where K: Send + Sync,

impl<'a, K, C> Send for SetCursor<'a, K, C>
where C: Sync, K: Send,

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

impl<'a, K, V, C> Send for MapCursor<'a, K, V, C>
where C: Sync, K: Send, V: Send,

impl<K> Send for Set<K>
where K: Send,

impl<K> Send for SetForest<K>
where K: Send,

impl<K, V> Send for Map<K, V>
where K: Send, V: Send,

impl<K, V> Send for MapForest<K, V>
where K: Send, V: Send,

impl<'a> Send for Iter<'a>

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

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

impl Send for Reloc

impl Send for DataValue

impl Send for FloatCC

impl Send for IntCC

impl Send for ValueDef

impl Send for AnyEntity

impl Send for AliasRegion

impl Send for AtomicRmwOp

impl Send for Endianness

impl Send for KnownSymbol

impl Send for LibCall

impl Send for Opcode

impl Send for BaseExpr

impl Send for Fact

impl Send for PccError

impl Send for CallConv

impl Send for LookupError

impl Send for UnwindInfo

impl Send for UnwindInst

impl Send for Amode

impl Send for AvxOpcode

impl Send for CC

impl Send for CmpOpcode

impl Send for ExtKind

impl Send for ExtMode

impl Send for FcmpImm

impl Send for FenceKind

impl Send for Imm8Reg

impl Send for OperandSize

impl Send for RegMem

impl Send for RegMemImm

impl Send for RoundImm

impl Send for ShiftKind

impl Send for SseOpcode

impl Send for EvexContext

impl Send for EvexMasking

impl Send for OpcodeMap

impl Send for MInst

impl Send for Detail

impl Send for OptLevel

impl Send for SetError

impl Send for SettingKind

impl Send for TlsModel

impl Send for Pass

impl Send for Event

impl Send for CodeInfo

impl Send for BlockData

impl Send for Blocks

impl Send for Insts

impl Send for Block

impl Send for Constant

impl Send for DynamicType

impl Send for FuncRef

impl Send for GlobalValue

impl Send for Immediate

impl Send for Inst

impl Send for JumpTable

impl Send for MemoryType

impl Send for SigRef

impl Send for StackSlot

impl Send for Value

impl Send for Function

impl Send for Ieee128

impl Send for Ieee16

impl Send for Ieee32

impl Send for Ieee64

impl Send for Imm64

impl Send for Offset32

impl Send for Uimm32

impl Send for Uimm64

impl Send for V128Imm

impl Send for BlockCall

impl Send for Layout

impl Send for Expr

impl Send for AbiParam

impl Send for ExtFuncData

impl Send for MemFlags

impl Send for Signature

impl Send for SourceLoc

impl Send for TrapCode

impl Send for ValueLabel

impl Send for Type

impl Send for UnwindInfo

impl Send for UnwindInfo

impl Send for UnwindInfo

impl Send for Gpr

impl Send for GprMem

impl Send for GprMemImm

impl Send for Imm8Gpr

impl Send for Imm8Xmm

impl Send for Xmm

impl Send for XmmMem

impl Send for XmmMemImm

impl Send for Register

impl Send for RexFlags

impl Send for Flags

impl Send for EmitInfo

impl Send for EmitState

impl Send for Loop

impl Send for LoopLevel

impl Send for Descriptor

impl Send for Template

impl Send for Builder

impl Send for Flags

impl Send for Setting

impl Send for Value

impl Send for Context

impl Send for Final

impl Send for MachLabel

impl Send for MachTrap

impl Send for PatchRegion

impl Send for RealReg

impl Send for Reg

impl Send for PassTimes

impl Send for Dfs

impl Send for PlainWriter

impl<'a> Send for CallInfo<'a>

impl<'a> Send for CFGPrinter<'a>

impl<'a> Send for DisplayDataValues<'a>

impl<'a> Send for ChildIter<'a>

impl<'a> Send for PredIter<'a>

impl<'a> Send for DisplayInst<'a>

impl<'a> Send for Values<'a>

impl<'a> Send for DisplayFunction<'a>

impl<'a> Send for DisplayBlockCall<'a>

impl<'a> Send for DisplayJumpTable<'a>

impl<'a> Send for FactContext<'a>

impl<'a> Send for FlagsOrIsa<'a>

impl<'a> Send for PredicateView<'a>

impl<'a> Send for CompileError<'a>

impl<'a> Send for DfsIter<'a>

impl<'a> Send for DfsPostOrderIter<'a>

impl<'a> Send for DfsPreOrderIter<'a>

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

impl<'f> Send for FuncCursor<'f>

impl<'f> Send for Blocks<'f>

impl<'f> Send for Insts<'f>

impl<'f> Send for ReplaceBuilder<'f>

impl<'f, IIB> Send for InsertBuilder<'f, IIB>
where IIB: Send,

impl<I> Send for MachBuffer<I>
where <I as MachInst>::LabelUse: Send,

impl<I> Send for MachTextSectionBuilder<I>
where <I as MachInst>::LabelUse: Send,

impl<T> Send for IsaBuilder<T>

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

impl<T> Send for MachBufferFinalized<T>
where <T as CompilePhase>::MachSrcLocType: Send,

impl<T> Send for MachSrcLoc<T>
where <T as CompilePhase>::SourceLocType: Send,

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

impl Send for Switch

impl Send for Variable

impl<'a> Send for FunctionBuilder<'a>

impl<'short, 'long> Send for FuncInstBuilder<'short, 'long>

impl<'a, W, I> Send for Digest<'a, W, I>
where W: Send + Sync, <I as Implementation>::Data<W>: Sync,

impl<W, I> Send for Crc<W, I>
where <I as Implementation>::Data<W>: Send, W: Sync,

impl<const L: usize> Send for Table<L>

impl<R> Send for Crc32cReader<R>
where R: Send,

impl<W> Send for Crc32cWriter<W>
where W: Send,

impl Send for Hasher

impl<W> Send for Algorithm<W>
where W: Send,

impl Send for RecvError

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

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

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

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

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

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

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

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

impl !Send for Guard

impl !Send for LocalHandle

impl<'g, T> !Send for Shared<'g, T>

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

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

impl Send for Backoff

impl Send for WaitGroup

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

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

impl<'env> Send for Scope<'env>

impl<'scope, 'env> Send for ScopedThreadBuilder<'scope, 'env>

impl Send for PublicKey

impl Send for SecretKey

impl<C> Send for CryptoBox<C>
where C: Send,

impl<C> Send for SecretBox<C>
where C: Send,

impl Send for Scalar

impl Send for BitOrder

impl Send for DecodeKind

impl Send for DecodeError

impl Send for Encoding

impl Send for Translate

impl Send for Wrap

impl<'a> Send for Display<'a>

impl<'a> Send for Encoder<'a>

impl Send for BuildError

impl Send for QueueMode

impl Send for TimeoutType

impl Send for Metrics

impl Send for PoolConfig

impl Send for Timeouts

impl Send for Status

impl<C> Send for CreatePoolError<C>
where C: Send,

impl<E> Send for HookError<E>
where E: Send,

impl<E> Send for PoolError<E>
where E: Send,

impl<E> Send for RecycleError<E>
where E: Send,

impl<M> Send for Hook<M>

impl<M> Send for Object<M>

impl<M, W> Send for Pool<M, W>

impl<M, W> Send for PoolBuilder<M, W>

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

impl Send for ConfigError

impl Send for SslMode

impl Send for Config

impl Send for Manager

impl<'a> Send for Transaction<'a>

impl<'a> Send for TransactionBuilder<'a>

impl<T> Send for ConfigConnectImpl<T>

impl Send for Runtime

impl Send for Class

impl Send for ErrorKind

impl Send for Tag

impl Send for TagMode

impl Send for Any

impl Send for BitString

impl Send for BmpString

impl Send for Ia5String

impl Send for Int

impl Send for Null

impl Send for OctetString

impl Send for Uint

impl Send for UtcTime

impl Send for DateTime

impl Send for Document

impl Send for Error

impl Send for Header

impl Send for Length

impl Send for TagNumber

impl<'a> Send for AnyRef<'a>

impl<'a> Send for BitStringIter<'a>

impl<'a> Send for BitStringRef<'a>

impl<'a> Send for Ia5StringRef<'a>

impl<'a> Send for IntRef<'a>

impl<'a> Send for OctetStringRef<'a>

impl<'a> Send for PrintableStringRef<'a>

impl<'a> Send for SequenceRef<'a>

impl<'a> Send for TeletexStringRef<'a>

impl<'a> Send for UintRef<'a>

impl<'a> Send for Utf8StringRef<'a>

impl<'a> Send for VideotexStringRef<'a>

impl<'a> Send for SliceReader<'a>

impl<'a> Send for SliceWriter<'a>

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

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

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

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

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

impl<'i> Send for PemReader<'i>

impl<'i, R> Send for NestedReader<'i, R>
where R: Send,

impl<'w> Send for PemWriter<'w>

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

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

impl<T, const N: usize> Send for SequenceOf<T, N>
where T: Send,

impl<T, const N: usize> Send for SetOf<T, N>
where T: Send,

impl<'a> Send for BerObjectContent<'a>

impl<'a> Send for BerObject<'a>

impl<'a> Send for BerObjectIntoIterator<'a>

impl<'a> Send for BerObjectRefIterator<'a>

impl<'a> Send for BitStringObject<'a>

impl<'a> Send for PrettyBer<'a>

impl<const MIN: i128, const MAX: i128> Send for OptionRangedI128<MIN, MAX>

impl<const MIN: i128, const MAX: i128> Send for RangedI128<MIN, MAX>

impl<const MIN: i16, const MAX: i16> Send for OptionRangedI16<MIN, MAX>

impl<const MIN: i16, const MAX: i16> Send for RangedI16<MIN, MAX>

impl<const MIN: i32, const MAX: i32> Send for OptionRangedI32<MIN, MAX>

impl<const MIN: i32, const MAX: i32> Send for RangedI32<MIN, MAX>

impl<const MIN: i64, const MAX: i64> Send for OptionRangedI64<MIN, MAX>

impl<const MIN: i64, const MAX: i64> Send for RangedI64<MIN, MAX>

impl<const MIN: i8, const MAX: i8> Send for OptionRangedI8<MIN, MAX>

impl<const MIN: i8, const MAX: i8> Send for RangedI8<MIN, MAX>

impl<const MIN: isize, const MAX: isize> Send for OptionRangedIsize<MIN, MAX>

impl<const MIN: isize, const MAX: isize> Send for RangedIsize<MIN, MAX>

impl<const MIN: u128, const MAX: u128> Send for OptionRangedU128<MIN, MAX>

impl<const MIN: u128, const MAX: u128> Send for RangedU128<MIN, MAX>

impl<const MIN: u16, const MAX: u16> Send for OptionRangedU16<MIN, MAX>

impl<const MIN: u16, const MAX: u16> Send for RangedU16<MIN, MAX>

impl<const MIN: u32, const MAX: u32> Send for OptionRangedU32<MIN, MAX>

impl<const MIN: u32, const MAX: u32> Send for RangedU32<MIN, MAX>

impl<const MIN: u64, const MAX: u64> Send for OptionRangedU64<MIN, MAX>

impl<const MIN: u64, const MAX: u64> Send for RangedU64<MIN, MAX>

impl<const MIN: u8, const MAX: u8> Send for OptionRangedU8<MIN, MAX>

impl<const MIN: u8, const MAX: u8> Send for RangedU8<MIN, MAX>

impl<const MIN: usize, const MAX: usize> Send for OptionRangedUsize<MIN, MAX>

impl<const MIN: usize, const MAX: usize> Send for RangedUsize<MIN, MAX>

impl Send for TruncSide

impl Send for MacError

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 CtOutput<T>

impl<T, OutSize, O> Send for CtVariableCoreWrapper<T, OutSize, O>
where T: Send, OutSize: Send, O: Send,

impl Send for BaseDirs

impl Send for ProjectDirs

impl Send for UserDirs

impl Send for Signature

impl Send for SigningKey

impl<'k, 'v, K> Send for Context<'k, 'v, K>
where K: Sync,

impl<L, R> Send for Either<L, R>
where L: Send, R: Send,

impl<L, R> Send for IterEither<L, R>
where L: Send, R: Send,

impl Send for CoderResult

impl Send for Latin1Bidi

impl Send for Decoder

impl Send for Encoder

impl Send for Encoding

impl Send for Blocking

impl<'a> Send for NonBlocking<'a>

impl<F> Send for FutureWrapper<F>
where F: Send + ?Sized,

impl<I> Send for Cloned<I>
where I: Send,

impl<I> Send for Convert<I>
where I: Send,

impl<I> Send for Cycle<I>
where I: Send,

impl<I> Send for Enumerate<I>
where I: Send,

impl<I> Send for Fuse<I>
where I: Send,

impl<I> Send for Iterator<I>
where I: Send,

impl<I> Send for Peekable<I>
where I: Send, <I as FallibleIterator>::Item: Send,

impl<I> Send for Rev<I>
where I: Send,

impl<I> Send for Skip<I>
where I: Send,

impl<I> Send for StepBy<I>
where I: Send,

impl<I> Send for Take<I>
where I: Send,

impl<I, F> Send for Filter<I, F>
where I: Send, F: Send,

impl<I, F> Send for FilterMap<I, F>
where I: Send, F: Send,

impl<I, F> Send for Inspect<I, F>
where I: Send, F: Send,

impl<I, F> Send for MapErr<I, F>
where I: Send, F: Send,

impl<I, P> Send for SkipWhile<I, P>
where I: Send, P: Send,

impl<I, P> Send for TakeWhile<I, P>
where I: Send, P: Send,

impl<I, St, F> Send for Scan<I, St, F>
where I: Send, F: Send, St: Send,

impl<I, U, F> Send for FlatMap<I, U, F>

impl<T, F> Send for Map<T, F>
where T: Send, F: Send,

impl<T, U> Send for Chain<T, U>
where T: Send, U: Send,

impl<T, U> Send for Zip<T, U>
where T: Send, U: Send,

impl Send for Rng

impl Send for FileTime

impl Send for InvalidBits

impl<F> Send for FlagSet<F>
where <F as Flags>::Type: Send,

impl Send for Status

impl Send for Compress

impl Send for Compression

impl Send for Crc

impl Send for Decompress

impl Send for GzBuilder

impl Send for GzHeader

impl<R> Send for DeflateDecoder<R>
where R: Send,

impl<R> Send for DeflateEncoder<R>
where R: Send,

impl<R> Send for GzDecoder<R>
where R: Send,

impl<R> Send for GzEncoder<R>
where R: Send,

impl<R> Send for MultiGzDecoder<R>
where R: Send,

impl<R> Send for ZlibDecoder<R>
where R: Send,

impl<R> Send for ZlibEncoder<R>
where R: Send,

impl<R> Send for DeflateDecoder<R>
where R: Send,

impl<R> Send for DeflateEncoder<R>
where R: Send,

impl<R> Send for GzDecoder<R>
where R: Send,

impl<R> Send for GzEncoder<R>
where R: Send,

impl<R> Send for MultiGzDecoder<R>
where R: Send,

impl<R> Send for ZlibDecoder<R>
where R: Send,

impl<R> Send for ZlibEncoder<R>
where R: Send,

impl<R> Send for CrcReader<R>
where R: Send,

impl<W> Send for CrcWriter<W>
where W: Send,

impl<W> Send for DeflateDecoder<W>
where W: Send,

impl<W> Send for DeflateEncoder<W>
where W: Send,

impl<W> Send for GzDecoder<W>
where W: Send,

impl<W> Send for GzEncoder<W>
where W: Send,

impl<W> Send for MultiGzDecoder<W>
where W: Send,

impl<W> Send for ZlibDecoder<W>
where W: Send,

impl<W> Send for ZlibEncoder<W>
where W: Send,

impl Send for FnvHasher

impl Send for FixedState

impl Send for FoldHasher

impl Send for RandomState

impl Send for FixedState

impl Send for FoldHasher

impl Send for RandomState

impl Send for SharedSeed

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

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

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

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

impl Send for DirEntry

impl Send for File

impl Send for OpenOptions

impl Send for ReadDir

impl Send for DirBuilder

impl Send for DirEntry

impl Send for File

impl Send for OpenOptions

impl Send for ReadDir

impl Send for SendError

impl Send for Canceled

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

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

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

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

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

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

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

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

impl !Send for LocalPool

impl !Send for LocalSpawner

impl Send for Enter

impl Send for EnterError

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

impl Send for YieldNow

impl Send for Empty

impl Send for Repeat

impl Send for Sink

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

impl<'r, 'ctx, T> !Send for AsyncAsSync<'r, 'ctx, T>

impl<A, B> Send for Zip<A, B>
where A: Send, B: Send, <A as Stream>::Item: Send,

impl<F> Send for CatchUnwind<F>
where F: Send,

impl<F> Send for PollFn<F>
where F: Send,

impl<F> Send for PollOnce<F>
where F: Send,

impl<F> Send for OnceFuture<F>
where F: Send,

impl<F> Send for PollFn<F>
where F: Send,

impl<F> Send for RepeatWith<F>
where F: Send,

impl<F1, F2> Send for Or<F1, F2>
where F1: Send, F2: Send,

impl<F1, F2> Send for Race<F1, F2>
where F1: Send, F2: Send,

impl<F1, F2> Send for TryZip<F1, F2>
where F1: Send, F2: Send, <F1 as Future>::Output: Send, <F2 as Future>::Output: Send,

impl<F1, F2> Send for Zip<F1, F2>
where F1: Send, F2: Send, <F1 as Future>::Output: Send, <F2 as Future>::Output: Send,

impl<I> Send for Iter<I>
where I: Send,

impl<R> Send for BufReader<R>
where R: Send,

impl<R> Send for Bytes<R>
where R: Send,

impl<R> Send for Lines<R>
where R: Send,

impl<R> Send for Split<R>
where R: Send,

impl<R> Send for Take<R>
where R: Send,

impl<R1, R2> Send for Chain<R1, R2>
where R1: Send, R2: Send,

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

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

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

impl<S> Send for CountFuture<S>
where S: Send + ?Sized,

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

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

impl<S> Send for Flatten<S>
where S: Send, <S as Stream>::Item: Send,

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

impl<S> Send for LastFuture<S>
where S: Send, <S as Stream>::Item: Send,

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

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

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

impl<S, C> Send for CollectFuture<S, C>
where S: Send, C: Send,

impl<S, C> Send for TryCollectFuture<S, C>
where S: Send, C: Send,

impl<S, F> Send for FilterMap<S, F>
where S: Send, F: Send,

impl<S, F> Send for ForEachFuture<S, F>
where S: Send, F: Send,

impl<S, F> Send for Inspect<S, F>
where S: Send, F: Send,

impl<S, F> Send for Map<S, F>
where S: Send, F: Send,

impl<S, F, Fut> Send for Then<S, F, Fut>
where S: Send, F: Send, Fut: Send,

impl<S, F, T> Send for FoldFuture<S, F, T>
where S: Send, F: Send, T: Send,

impl<S, FromA, FromB> Send for UnzipFuture<S, FromA, FromB>
where S: Send, FromA: Send, FromB: Send,

impl<S, P> Send for Filter<S, P>
where S: Send, P: Send,

impl<S, P> Send for SkipWhile<S, P>
where S: Send, P: Send,

impl<S, P> Send for TakeWhile<S, P>
where S: Send, P: Send,

impl<S, P, B> Send for PartitionFuture<S, P, B>
where S: Send, P: Send, B: Send,

impl<S, St, F> Send for Scan<S, St, F>
where S: Send, St: Send, F: Send,

impl<S, U> Send for Chain<S, U>
where S: Send, U: Send,

impl<S, U, F> Send for FlatMap<S, U, F>
where S: Send, F: Send, U: Send,

impl<S1, S2> Send for Or<S1, S2>
where S1: Send, S2: Send,

impl<S1, S2> Send for Race<S1, S2>
where S1: Send, S2: Send,

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

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

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

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

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

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

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

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

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

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

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

impl<T, F, Fut> Send for TryUnfold<T, F, Fut>
where F: Send, T: Send, Fut: Send,

impl<T, F, Fut> Send for Unfold<T, F, Fut>
where F: Send, T: Send, Fut: Send,

impl<W> Send for BufWriter<W>
where W: Send,

impl Send for SpawnError

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

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

impl Send for PollNext

impl Send for AbortHandle

impl Send for Aborted

impl Send for Empty

impl Send for Repeat

impl Send for Sink

impl<'a, Fut> Send for Iter<'a, Fut>
where Fut: Send,

impl<'a, Fut> Send for IterMut<'a, Fut>
where Fut: 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, 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, Si, Item> Send for 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 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 Iter<'a, St>
where St: Send,

impl<'a, St> Send for IterMut<'a, St>
where St: Send,

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

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

impl<'a, St> Send for 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, W> Send for Close<'a, W>
where W: Send + ?Sized,

impl<'a, W> Send for 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, B> Send for Either<A, B>
where A: Send, B: Send,

impl<A, B> Send for Select<A, B>
where A: Send, B: Send,

impl<A, B> Send for TrySelect<A, B>
where A: Send, B: Send,

impl<F> Send for 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 IntoStream<F>
where F: Send,

impl<F> Send for JoinAll<F>
where F: Send, <F as Future>::Output: Send,

impl<F> Send for Lazy<F>
where F: Send,

impl<F> Send for OptionFuture<F>
where F: Send,

impl<F> Send for 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 PollFn<F>
where F: Send,

impl<F> Send for RepeatWith<F>
where F: 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 CatchUnwind<Fut>
where Fut: Send,

impl<Fut> Send for 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 SelectAll<Fut>
where Fut: Send,

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

impl<Fut> Send for 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 UnitError<Fut>
where Fut: Send,

impl<Fut> Send for WeakShared<Fut>
where Fut: Send, <Fut as Future>::Output: Send + Sync,

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

impl<Fut, E> Send for ErrInto<Fut, E>
where Fut: Send,

impl<Fut, E> Send for OkInto<Fut, E>
where Fut: Send,

impl<Fut, F> Send for Inspect<Fut, F>
where Fut: Send, F: Send,

impl<Fut, F> Send for InspectErr<Fut, F>
where Fut: Send, F: Send,

impl<Fut, F> Send for InspectOk<Fut, F>
where Fut: Send, F: Send,

impl<Fut, F> Send for Map<Fut, F>
where Fut: Send, F: Send,

impl<Fut, F> Send for MapErr<Fut, F>
where Fut: Send, F: Send,

impl<Fut, F> Send for 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 MapInto<Fut, T>
where Fut: Send,

impl<Fut1, Fut2> Send for Join<Fut1, Fut2>
where Fut1: Send, <Fut1 as Future>::Output: Send, Fut2: Send, <Fut2 as Future>::Output: Send,

impl<Fut1, Fut2> Send for 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 AndThen<Fut1, Fut2, F>
where Fut2: Send, Fut1: Send, F: Send,

impl<Fut1, Fut2, F> Send for OrElse<Fut1, Fut2, F>
where Fut2: Send, Fut1: Send, F: Send,

impl<Fut1, Fut2, F> Send for 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<I> Send for Iter<I>
where I: Send,

impl<R> Send for BufReader<R>
where R: Send,

impl<R> Send for Lines<R>
where R: Send,

impl<R> Send for Take<R>
where R: Send,

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

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

impl<S, Item> Send for SplitSink<S, Item>
where Item: Send, S: Send,

impl<Si, F> Send for SinkMapErr<Si, F>
where Si: Send, F: Send,

impl<Si, Item> Send for 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<Si1, Si2> Send for Fanout<Si1, Si2>
where Si1: Send, Si2: Send,

impl<St> Send for 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 CatchUnwind<St>
where St: Send,

impl<St> Send for 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 Count<St>
where St: Send,

impl<St> Send for Cycle<St>
where St: Send,

impl<St> Send for Enumerate<St>
where St: Send,

impl<St> Send for Flatten<St>
where St: Send, <St as Stream>::Item: Send,

impl<St> Send for Fuse<St>
where St: Send,

impl<St> Send for IntoAsyncRead<St>
where St: Send, <St as TryStream>::Ok: Send,

impl<St> Send for IntoStream<St>
where St: Send,

impl<St> Send for Peekable<St>
where St: Send, <St as Stream>::Item: Send,

impl<St> Send for ReadyChunks<St>
where St: Send,

impl<St> Send for SelectAll<St>
where St: Send,

impl<St> Send for Skip<St>
where St: Send,

impl<St> Send for StreamFuture<St>
where St: Send,

impl<St> Send for 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 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 ErrInto<St, E>
where St: Send,

impl<St, F> Send for Inspect<St, F>
where St: Send, F: Send,

impl<St, F> Send for InspectErr<St, F>
where St: Send, F: Send,

impl<St, F> Send for InspectOk<St, F>
where St: Send, F: Send,

impl<St, F> Send for Map<St, F>
where St: Send, F: Send,

impl<St, F> Send for MapErr<St, F>
where St: Send, F: Send,

impl<St, F> Send for MapOk<St, F>
where St: Send, F: Send,

impl<St, FromA, FromB> Send for Unzip<St, FromA, FromB>
where St: Send, FromA: Send, FromB: Send,

impl<St, Fut> Send for 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 AndThen<St, Fut, F>
where St: Send, F: Send, Fut: Send,

impl<St, Fut, F> Send for Any<St, Fut, F>
where St: Send, F: Send, Fut: Send,

impl<St, Fut, F> Send for Filter<St, Fut, F>
where St: Send, F: Send, Fut: Send, <St as Stream>::Item: Send,

impl<St, Fut, F> Send for 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 OrElse<St, Fut, F>
where St: Send, F: Send, Fut: Send,

impl<St, Fut, F> Send for SkipWhile<St, Fut, F>
where St: Send, F: Send, Fut: Send, <St as Stream>::Item: Send,

impl<St, Fut, F> Send for TakeWhile<St, Fut, F>
where St: Send, F: Send, Fut: Send, <St as Stream>::Item: Send,

impl<St, Fut, F> Send for 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 Fold<St, Fut, T, F>
where St: Send, F: Send, T: Send, Fut: Send,

impl<St, Fut, T, F> Send for TryFold<St, Fut, T, F>
where St: Send, F: Send, T: Send, Fut: Send,

impl<St, S, Fut, F> Send for 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 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<St1, St2> Send for Chain<St1, St2>
where St2: Send, St1: Send,

impl<St1, St2> Send for Select<St1, St2>
where St1: Send, St2: Send,

impl<St1, St2> Send for 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<T> Send for Abortable<T>
where T: Send,

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

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

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

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

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

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

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

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

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

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

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

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

impl<T> Send for FuturesOrdered<T>
where T: Send, <T as Future>::Output: Send,

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

impl<T> Send for Repeat<T>
where T: 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, F> Send for AlwaysReady<T, F>
where 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 Unfold<T, F, Fut>
where F: Send, T: Send, Fut: Send,

impl<T, F, R> Send for Unfold<T, F, R>
where F: Send, T: Send, R: Send,

impl<T, Item> Send for ReuniteError<T, Item>
where Item: Send, T: Send,

impl<T, U> Send for Chain<T, U>
where T: Send, U: Send,

impl<W> Send for BufWriter<W>
where W: Send,

impl<W> Send for LineWriter<W>
where W: Send,

impl<W, Item> Send for IntoSink<W, Item>
where W: Send, Item: Send,

impl<T, N> Send for GenericArrayIter<T, N>
where T: Send,

impl Send for Error

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

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

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

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

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

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

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

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

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

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

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

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

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

impl Send for Error

impl Send for Format

impl Send for SectionId

impl Send for Vendor

impl Send for ColumnType

impl Send for Error

impl Send for Pointer

impl Send for Value

impl Send for ValueType

impl Send for Address

impl Send for Error

impl Send for LineString

impl Send for Location

impl Send for Range

impl Send for Reference

impl Send for DwAccess

impl Send for DwAddr

impl Send for DwAt

impl Send for DwAte

impl Send for DwCc

impl Send for DwCfa

impl Send for DwChildren

impl Send for DwDefaulted

impl Send for DwDs

impl Send for DwDsc

impl Send for DwEhPe

impl Send for DwEnd

impl Send for DwForm

impl Send for DwId

impl Send for DwIdx

impl Send for DwInl

impl Send for DwLang

impl Send for DwLle

impl Send for DwLnct

impl Send for DwLne

impl Send for DwLns

impl Send for DwMacro

impl Send for DwOp

impl Send for DwOrd

impl Send for DwRle

impl Send for DwSect

impl Send for DwSectV2

impl Send for DwTag

impl Send for DwUt

impl Send for DwVis

impl Send for ArangeEntry

impl Send for LineRow

impl Send for Range

impl Send for StoreOnHeap

impl Send for AArch64

impl Send for Arm

impl Send for BigEndian

impl Send for DwoId

impl Send for Encoding

impl Send for LoongArch

impl Send for MIPS

impl Send for PowerPc64

impl Send for Register

impl Send for RiscV

impl Send for X86

impl Send for X86_64

impl Send for Attribute

impl Send for CieId

impl Send for DirectoryId

impl Send for Dwarf

impl Send for DwarfUnit

impl Send for Expression

impl Send for FileId

impl Send for FileInfo

impl Send for FrameTable

impl Send for LineProgram

impl Send for LineRow

impl Send for RangeList

impl Send for RangeListId

impl Send for Relocation

impl Send for StringId

impl Send for StringTable

impl Send for Unit

impl Send for UnitEntryId

impl Send for UnitId

impl Send for UnitTable

impl<'a, 'bases, R> Send for EhHdrTableIter<'a, 'bases, R>
where R: Send + Sync,

impl<'a, 'ctx, R, S> Send for UnwindTable<'a, 'ctx, R, S>
where R: Send + Sync, <<S as UnwindContextStorage<<R as Reader>::Offset>>::Stack as Sealed>::Storage: Send, <R as Reader>::Offset: Send,

impl<'a, R> Send for CallFrameInstructionIter<'a, R>
where R: Send + Sync,

impl<'a, R> Send for EhHdrTable<'a, R>
where R: Sync,

impl<'a, R> Send for UnitRef<'a, R>
where R: Sync + Send, <R as Reader>::Offset: Sync,

impl<'abbrev, 'entry, 'unit, R> !Send for AttrsIter<'abbrev, 'entry, 'unit, R>

impl<'abbrev, 'unit, 'tree, R> Send for EntriesTreeIter<'abbrev, 'unit, 'tree, R>
where R: Send + Sync, <R as Reader>::Offset: Sync + Send,

impl<'abbrev, 'unit, 'tree, R> Send for EntriesTreeNode<'abbrev, 'unit, 'tree, R>
where R: Send + Sync, <R as Reader>::Offset: Sync + Send,

impl<'abbrev, 'unit, R> Send for EntriesCursor<'abbrev, 'unit, R>
where R: Send + Sync, <R as Reader>::Offset: Sync + Send,

impl<'abbrev, 'unit, R> Send for EntriesRaw<'abbrev, 'unit, R>
where R: Send + Sync, <R as Reader>::Offset: Sync,

impl<'abbrev, 'unit, R> Send for EntriesTree<'abbrev, 'unit, R>
where R: Send + Sync, <R as Reader>::Offset: Sync + Send,

impl<'abbrev, 'unit, R, Offset> Send for DebuggingInformationEntry<'abbrev, 'unit, R, Offset>
where R: Send + Sync, Offset: Send + Sync,

impl<'bases, Section, R> Send for CieOrFde<'bases, Section, R>
where <R as Reader>::Offset: Send, R: Send, <Section as UnwindSection<R>>::Offset: Send, Section: Send,

impl<'bases, Section, R> Send for CfiEntriesIter<'bases, Section, R>
where Section: Send, R: Send,

impl<'bases, Section, R> Send for PartialFrameDescriptionEntry<'bases, Section, R>
where <R as Reader>::Offset: Send, <Section as UnwindSection<R>>::Offset: Send, R: Send, Section: Send,

impl<'index, R> Send for UnitIndexSectionIterator<'index, R>
where R: Send,

impl<'input, Endian> Send for EndianSlice<'input, Endian>
where Endian: Send,

impl<'iter, T> Send for RegisterRuleIter<'iter, T>
where T: Sync,

impl<Endian> Send for EndianVec<Endian>
where Endian: Send,

impl<Offset> Send for UnitType<Offset>
where Offset: Send,

impl<R> Send for EvaluationResult<R>
where <R as Reader>::Offset: Send, R: Send,

impl<R> Send for RawLocListEntry<R>
where R: Send, <R as Reader>::Offset: Send,

impl<R> Send for ArangeEntryIter<R>
where R: Send,

impl<R> Send for ArangeHeaderIter<R>
where R: Send, <R as Reader>::Offset: Send,

impl<R> Send for Attribute<R>
where R: Send, <R as Reader>::Offset: Send,

impl<R> Send for DebugAbbrev<R>
where R: Send,

impl<R> Send for DebugAddr<R>
where R: Send,

impl<R> Send for DebugAranges<R>
where R: Send,

impl<R> Send for DebugCuIndex<R>
where R: Send,

impl<R> Send for DebugFrame<R>
where R: Send,

impl<R> Send for DebugInfo<R>
where R: Send,

impl<R> Send for DebugInfoUnitHeadersIter<R>
where R: Send, <R as Reader>::Offset: Send,

impl<R> Send for DebugLine<R>
where R: Send,

impl<R> Send for DebugLineStr<R>
where R: Send,

impl<R> Send for DebugLoc<R>
where R: Send,

impl<R> Send for DebugLocLists<R>
where R: Send,

impl<R> Send for DebugPubNames<R>
where R: Send, <R as Reader>::Offset: Send,

impl<R> Send for DebugPubTypes<R>
where R: Send, <R as Reader>::Offset: Send,

impl<R> Send for DebugRanges<R>
where R: Send,

impl<R> Send for DebugRngLists<R>
where R: Send,

impl<R> Send for DebugStr<R>
where R: Send,

impl<R> Send for DebugStrOffsets<R>
where R: Send,

impl<R> Send for DebugTuIndex<R>
where R: Send,

impl<R> Send for DebugTypes<R>
where R: Send,

impl<R> Send for DebugTypesUnitHeadersIter<R>
where R: Send, <R as Reader>::Offset: Send,

impl<R> Send for Dwarf<R>
where R: Send + Sync,

impl<R> Send for DwarfPackage<R>
where R: Send,

impl<R> Send for EhFrame<R>
where R: Send,

impl<R> Send for EhFrameHdr<R>
where R: Send,

impl<R> Send for Expression<R>
where R: Send,

impl<R> Send for LineInstructions<R>
where R: Send,

impl<R> Send for LineSequence<R>
where R: Send,

impl<R> Send for LocListIter<R>
where R: Send, <R as Reader>::Offset: Send,

impl<R> Send for LocationListEntry<R>
where R: Send,

impl<R> Send for LocationLists<R>
where R: Send,

impl<R> Send for OperationIter<R>
where R: Send,

impl<R> Send for ParsedEhFrameHdr<R>
where R: Send,

impl<R> Send for PubNamesEntry<R>
where R: Send, <R as Reader>::Offset: Send,

impl<R> Send for PubNamesEntryIter<R>
where R: Send, <R as Reader>::Offset: Send,

impl<R> Send for PubTypesEntry<R>
where R: Send, <R as Reader>::Offset: Send,

impl<R> Send for PubTypesEntryIter<R>
where R: Send, <R as Reader>::Offset: Send,

impl<R> Send for RangeIter<R>
where R: Send, <R as Reader>::Offset: Send,

impl<R> Send for RangeLists<R>
where R: Send,

impl<R> Send for RawLocListIter<R>
where R: Send,

impl<R> Send for RawRngListIter<R>
where R: Send,

impl<R> Send for RngListIter<R>
where R: Send, <R as Reader>::Offset: Send,

impl<R> Send for UnitIndex<R>
where R: Send,

impl<R, Offset> Send for AttributeValue<R, Offset>
where R: Send, Offset: Send,

impl<R, Offset> Send for LineInstruction<R, Offset>
where R: Send, Offset: Send,

impl<R, Offset> Send for Location<R, Offset>
where R: Send, Offset: Send,

impl<R, Offset> Send for Operation<R, Offset>
where R: Send, Offset: Send,

impl<R, Offset> Send for ArangeHeader<R, Offset>
where Offset: Send, R: Send,

impl<R, Offset> Send for CommonInformationEntry<R, Offset>
where Offset: Send, R: Send,

impl<R, Offset> Send for CompleteLineProgram<R, Offset>
where Offset: Send, R: Send,

impl<R, Offset> Send for FileEntry<R, Offset>
where R: Send, Offset: Send,

impl<R, Offset> Send for FrameDescriptionEntry<R, Offset>
where Offset: Send, R: Send,

impl<R, Offset> Send for IncompleteLineProgram<R, Offset>
where Offset: Send, R: Send,

impl<R, Offset> Send for LineProgramHeader<R, Offset>
where Offset: Send, R: Send,

impl<R, Offset> Send for Piece<R, Offset>
where R: Send, Offset: Send,

impl<R, Offset> Send for Unit<R, Offset>
where Offset: Send, R: Send,

impl<R, Offset> Send for UnitHeader<R, Offset>
where Offset: Send, R: Send,

impl<R, Program, Offset> Send for LineRows<R, Program, Offset>
where Program: Send, R: Send,

impl<R, S> Send for Evaluation<R, S>
where R: Send, <<S as EvaluationStorage<R>>::Stack as Sealed>::Storage: Send, <<S as EvaluationStorage<R>>::ExpressionStack as Sealed>::Storage: Send, <<S as EvaluationStorage<R>>::Result as Sealed>::Storage: Send,

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

impl<T, S> Send for UnwindContext<T, S>
where <<S as UnwindContextStorage<T>>::Stack as Sealed>::Storage: Send, T: Send,

impl<T, S> Send for UnwindTableRow<T, S>
where T: Send, <<S as UnwindContextStorage<T>>::Rules as Sealed>::Storage: Send,

impl<W> Send for DebugAbbrev<W>
where W: Send,

impl<W> Send for DebugFrame<W>
where W: Send,

impl<W> Send for DebugInfo<W>
where W: Send,

impl<W> Send for DebugLine<W>
where W: Send,

impl<W> Send for DebugLineStr<W>
where W: Send,

impl<W> Send for DebugLoc<W>
where W: Send,

impl<W> Send for DebugLocLists<W>
where W: Send,

impl<W> Send for DebugRanges<W>
where W: Send,

impl<W> Send for DebugRngLists<W>
where W: Send,

impl<W> Send for DebugStr<W>
where W: Send,

impl<W> Send for EhFrame<W>
where W: Send,

impl<W> Send for Sections<W>
where W: Send,

impl Send for GlobError

impl Send for Paths

impl Send for Pattern

impl Send for Builder

impl Send for PushPromise

impl Send for Protocol

impl Send for Builder

impl Send for Error

impl Send for FlowControl

impl Send for Ping

impl Send for PingPong

impl Send for Pong

impl Send for Reason

impl Send for RecvStream

impl Send for StreamId

impl<B> Send for ReadySendRequest<B>
where B: Send,

impl<B> Send for SendRequest<B>
where B: Send,

impl<B> Send for SendPushedResponse<B>
where B: Send,

impl<B> Send for SendResponse<B>
where B: Send,

impl<B> Send for SendStream<B>
where B: Send,

impl<T, B> Send for Connection<T, B>
where T: Send, B: Send,

impl<T, B> Send for Connection<T, B>
where T: Send, B: Send,

impl<T, B> Send for Handshake<T, B>
where T: Send, B: Send,

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

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

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

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

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

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

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

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

impl<D> Send for HmacCore<D>
where <D as CoreProxy>::Core: Sized + Send,

impl<D> Send for SimpleHmac<D>
where D: Send,

impl Send for HeaderName

impl Send for HeaderValue

impl Send for ToStrError

impl Send for Method

impl Send for Builder

impl Send for Parts

impl Send for Builder

impl Send for Parts

impl Send for StatusCode

impl Send for Error

impl Send for Extensions

impl Send for Authority

impl Send for Builder

impl Send for InvalidUri

impl Send for Parts

impl Send for Scheme

impl Send for Uri

impl Send for Version

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

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

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

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

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

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

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

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

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

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

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

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

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

impl Send for ToStrError

impl<'a> Send for PasswordParams<'a>

impl<'i> Send for ChallengeParser<'i>

impl<'i> Send for Error<'i>

impl<'i> Send for ChallengeRef<'i>

impl<'i> Send for ParamValue<'i>

impl Send for SizeHint

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

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

impl<B> Send for BodyDataStream<B>
where B: Send,

impl<B> Send for BodyStream<B>
where B: Send,

impl<B> Send for Collected<B>
where B: Send,

impl<B> Send for Limited<B>
where B: Send,

impl<B, F> Send for MapErr<B, F>
where B: Send, F: Send,

impl<B, F> Send for MapFrame<B, F>
where B: Send, F: Send,

impl<D> Send for Empty<D>

impl<D> Send for Full<D>
where D: Send,

impl<D, E> Send for BoxBody<D, E>

impl<D, E> Send for UnsyncBoxBody<D, E>

impl<L, R> Send for Either<L, R>
where L: Send, R: Send,

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

impl<T> Send for Collect<T>
where T: Send + ?Sized, <T as Body>::Data: Send,

impl<T, F> Send for WithTrailers<T, F>
where T: Send, F: Send,

impl Send for ETag

impl Send for Encoding

impl Send for Method

impl Send for StatusCode

impl Send for Version

impl Send for Source

impl Send for Encoding

impl Send for BasicAuth

impl Send for Age

impl Send for Expires

impl Send for IntoIter

impl Send for IntoIter

impl Send for IfMatch

impl Send for IfNoneMatch

impl Send for Vary

impl Send for IntoIter

impl Send for IntoIter

impl Send for Accept

impl Send for ContentType

impl Send for HeaderName

impl Send for HeaderValue

impl Send for IntoIter

impl Send for ParamName

impl Send for ParamValue

impl Send for Date

impl Send for Expect

impl Send for Referer

impl Send for RetryAfter

impl Send for SourceMap

impl Send for ReportTo

impl Send for IntoIter

impl Send for Allow

impl Send for Body

impl Send for Error

impl Send for Extensions

impl Send for Headers

impl Send for Mime

impl Send for Request

impl Send for Response

impl Send for Trailers

impl Send for IntoIter

impl Send for Metric

impl Send for Receiver

impl Send for Sender

impl Send for TE

impl Send for Connection

impl Send for Receiver

impl Send for Sender

impl<'a> Send for Iter<'a>

impl<'a> Send for IterMut<'a>

impl<'a> Send for Iter<'a>

impl<'a> Send for IterMut<'a>

impl<'a> Send for Iter<'a>

impl<'a> Send for IterMut<'a>

impl<'a> Send for Iter<'a>

impl<'a> Send for IterMut<'a>

impl<'a> Send for Iter<'a>

impl<'a> Send for IterMut<'a>

impl<'a> Send for Names<'a>

impl<'a> Send for Values<'a>

impl<'a> Send for Forwarded<'a>

impl<'a> Send for Iter<'a>

impl<'a> Send for Iter<'a>

impl<'a> Send for IterMut<'a>

impl Send for Error

impl<'a> Send for Header<'a>

impl<'headers, 'buf> Send for Request<'headers, 'buf>

impl<'headers, 'buf> Send for Response<'headers, 'buf>

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

impl Send for Error

impl Send for HttpDate

impl Send for Error

impl Send for Error

impl Send for Duration

impl Send for Timestamp

impl Send for Incoming

impl Send for Builder

impl Send for Protocol

impl Send for Builder

impl Send for Error

impl Send for OnUpgrade

impl Send for Upgraded

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

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

impl<B> Send for SendRequest<B>
where B: Send,

impl<B> Send for SendRequest<B>
where B: Send,

impl<E> Send for Builder<E>
where E: Send,

impl<Ex> Send for Builder<Ex>
where Ex: Send,

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

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

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

impl<T, B> Send for Connection<T, B>
where T: Send, B: Send, <B as Body>::Data: Send,

impl<T, B, E> Send for Connection<T, B, E>
where <B as Body>::Error: Sized, T: Send, E: Send, B: Send, <B as Body>::Data: Send,

impl<T, S> Send for Connection<T, S>

impl<T, S> Send for Parts<T, S>
where T: Send, S: Send,

impl<T, S> Send for UpgradeableConnection<T, S>

impl<T, S, E> Send for Connection<T, S, E>
where E: Send, S: Send, T: Send, <<S as HttpService<Incoming>>::ResBody as Body>::Data: Send,

impl<State> Send for ConnectorBuilder<State>
where State: Send,

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

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

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

impl Send for GaiAddrs

impl Send for GaiFuture

impl Send for GaiResolver

impl Send for Name

impl Send for Connected

impl Send for HttpInfo

impl Send for Builder

impl Send for Error

impl Send for TokioTimer

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

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

impl<'a, I, S, E> Send for Connection<'a, I, S, E>
where S: Send, I: Send, E: Send + Sync, <S as HttpService<Incoming>>::ResBody: Send, <S as HttpService<Incoming>>::Future: Send, <<S as HttpService<Incoming>>::ResBody as Body>::Data: Send,

impl<'a, I, S, E> Send for UpgradeableConnection<'a, I, S, E>
where S: Send, I: Send, E: Send + Sync, <S as HttpService<Incoming>>::ResBody: Send, <S as HttpService<Incoming>>::Future: Send, <<S as HttpService<Incoming>>::ResBody as Body>::Data: Send,

impl<C, B> Send for Client<C, B>
where C: Send, B: Send,

impl<E> Send for Builder<E>
where E: Send,

impl<I> Send for WithHyperIo<I>
where I: Send,

impl<I> Send for WithTokioIo<I>
where I: Send,

impl<R> Send for HttpConnector<R>
where R: Send,

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

impl<S, R> Send for TowerToHyperServiceFuture<S, R>
where S: Send, <S as Service<R>>::Future: Send, R: Send,

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

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

impl Send for TrieResult

impl Send for Error

impl Send for TrieType

impl<'a> Send for Char16TrieIterator<'a>

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

impl<'data> Send for Char16Trie<'data>

impl<'data> Send for CodePointInversionList<'data>

impl<'trie, T> Send for CodePointTrie<'trie, T>
where T: Send, <T as AsULE>::ULE: Send + Sync,

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

impl Send for ParserError

impl Send for Other

impl Send for Subtag

impl Send for Private

impl Send for Subtag

impl Send for Extensions

impl Send for Fields

impl Send for Key

impl Send for Transform

impl Send for Value

impl Send for Attribute

impl Send for Attributes

impl Send for Key

impl Send for Keywords

impl Send for Unicode

impl Send for Value

impl Send for Locale

impl Send for Language

impl Send for Region

impl Send for Script

impl Send for Variant

impl Send for Variants

impl<I> Send for SubtagOrderingResult<I>
where I: Send,

impl Send for Direction

impl Send for Baked

impl<'a> Send for LanguageStrStrPair<'a>

impl<'a> Send for StrStrPair<'a>

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

impl<'data> Send for AliasesV1<'data>

impl<'data> Send for AliasesV2<'data>

impl<'data> Send for LikelySubtagsExtendedV1<'data>

impl<'data> Send for LikelySubtagsForLanguageV1<'data>

impl<'data> Send for LikelySubtagsForScriptRegionV1<'data>

impl<'data> Send for LikelySubtagsV1<'data>

impl<'data> Send for LocaleFallbackLikelySubtagsV1<'data>

impl<'data> Send for LocaleFallbackParentsV1<'data>

impl<'data> Send for LocaleFallbackSupplementV1<'data>

impl<'data> Send for ScriptDirectionV1<'data>

impl !Send for Uts46Mapper

impl Send for Decomposed

impl Send for Baked

impl<'data> Send for CanonicalCompositionsV1<'data>

impl<'data> Send for DecompositionDataV1<'data>

impl<'data> Send for DecompositionSupplementV1<'data>

impl<'data> Send for DecompositionTablesV1<'data>

impl<'data, I> Send for Composition<'data, I>
where I: Send,

impl<'data, I> Send for Decomposition<'data, I>
where I: Send,

impl Send for Baked

impl Send for BidiClass

impl Send for JoiningType

impl Send for LineBreak

impl Send for Script

impl Send for WordBreak

impl<'a> Send for ScriptExtensionsSet<'a>

impl<'a> Send for UnicodeSetDataBorrowed<'a>

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

impl<'data> Send for PropertyCodePointSetV1<'data>

impl<'data> Send for PropertyUnicodeSetV1<'data>

impl<'data> Send for BidiAuxiliaryPropertiesV1<'data>

impl<'data> Send for PropertyValueNameToEnumMapV1<'data>

impl<'data> Send for ScriptWithExtensionsPropertyV1<'data>

impl<'data, T> Send for PropertyCodePointMapV1<'data, T>
where T: Send, <T as AsULE>::ULE: Send + Sync,

impl<T> !Send for CodePointMapData<T>

impl !Send for AnyPayload

impl !Send for AnyResponse

impl !Send for Cart

impl Send for AnyMarker

impl Send for DataError

impl Send for DataKey

impl Send for DataKeyHash

impl Send for DataKeyPath

impl Send for DataLocale

impl<'a> Send for DataRequest<'a>

impl<'a, P> Send for DowncastingAnyProvider<'a, P>
where P: Sync + ?Sized,

impl<'a, P> Send for DynamicDataProviderAnyMarkerWrap<'a, P>
where P: Sync + ?Sized,

impl<'data> Send for HelloWorldV1<'data>

impl<'l> Send for FormattedHelloWorld<'l>

impl<M> !Send for DataPayload<M>

impl<M> !Send for DataResponse<M>

impl<M, P> Send for DataProviderWithKey<M, P>
where P: Send, M: Send,

impl<Y> Send for NeverMarker<Y>
where Y: Send,

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

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

impl<T> Send for DefaultArenaBehavior<T>

impl<T> Send for Id<T>

impl<T, A> Send for Arena<T, A>
where T: Send,

impl<T, A> Send for IntoIter<T, A>
where T: Send,

impl !Send for Uts46

impl Send for DnsLength

impl Send for ErrorPolicy

impl Send for Hyphens

impl Send for Config

impl Send for Errors

impl Send for Idna

impl !Send for Adapter

impl Send for BidiClass

impl Send for JoiningType

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

impl<'a, I, T, S> Send for Splice<'a, I, T, S>
where I: Send, S: Send, T: Send,

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

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

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

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

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

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

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

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

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

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

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

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

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 S: Sync, K: Send, V: Send,

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

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

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

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

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

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

impl<'a, T, S1, S2> Send for SymmetricDifference<'a, T, S1, S2>
where T: Sync, S2: Sync, S1: Sync,

impl<K, V> Send for IntoIter<K, V>
where K: Send, V: Send,

impl<K, V> Send for IntoKeys<K, V>
where K: Send, V: Send,

impl<K, V> Send for IntoValues<K, V>
where K: Send, V: Send,

impl<K, V> Send for Slice<K, V>
where K: Send, V: Send,

impl<K, V, S> Send for IndexMap<K, V, S>
where S: Send, K: Send, V: Send,

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

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

impl<T, S> Send for IndexSet<T, S>
where S: Send, T: Send,

impl Send for Infer

impl Send for Type

impl<'inp, 'out, T> !Send for InOut<'inp, 'out, T>

impl<'inp, 'out, T> !Send for InOutBuf<'inp, 'out, T>

impl<'inp, 'out, T> !Send for InOutBufIter<'inp, 'out, T>

impl<'inp, 'out, T> !Send for InOutBufReserved<'inp, 'out, T>

impl Send for RawReadable

impl<'a> Send for BorrowedReadable<'a>

impl<'a> Send for BorrowedWriteable<'a>

impl<'a, RW> Send for ReadHalf<'a, RW>
where RW: Sync,

impl<'a, RW> Send for WriteHalf<'a, RW>
where RW: Sync,

impl<'filelike, Target> Send for FilelikeView<'filelike, Target>
where Target: Send,

impl<'socketlike, Target> Send for SocketlikeView<'socketlike, Target>
where Target: Send,

impl Send for IpAddrRange

impl Send for IpNet

impl Send for IpSubnets

impl Send for Ipv4Net

impl Send for Ipv4Subnets

impl Send for Ipv6Net

impl Send for Ipv6Subnets

impl Send for Position

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

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

impl<'a, I> Send for Format<'a, I>
where I: 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, I, F> !Send for Group<'a, K, I, F>

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

impl<A> Send for RepeatN<A>
where A: Send,

impl<A, B> Send for EitherOrBoth<A, B>
where A: Send, B: Send,

impl<F> Send for RepeatCall<F>
where F: Send,

impl<I> !Send for RcIter<I>

impl<I> !Send for Tee<I>

impl<I> Send for Combinations<I>
where I: Send, <I as Iterator>::Item: 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 Step<I>
where I: Send,

impl<I> Send for Unique<I>
where <I as Iterator>::Item: Sized + Send, I: Send,

impl<I> Send for WhileSome<I>
where I: Send,

impl<I> Send for WithPosition<I>
where I: Send, <I as Iterator>::Item: Send,

impl<I, ElemF> Send for 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 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 Update<I, F>
where I: 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 ConsTuples<I, J>
where I: Send,

impl<I, J> Send for Interleave<I, J>
where I: Send, J: Send,

impl<I, J> Send for 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 ZipEq<I, J>
where I: Send, J: Send,

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, 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, V, F> Send for UniqueBy<I, V, F>
where I: Send, F: Send, V: Send,

impl<K, I, F> Send for GroupBy<K, I, F>
where F: Send, I: Send, K: Send, <I as Iterator>::Item: Send,

impl<St, F> Send for Iterate<St, F>
where St: Send, F: Send,

impl<St, F> Send for Unfold<St, F>
where F: Send, St: Send,

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

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

impl<T> Send for TupleBuffer<T>
where <T as TupleCollect>::Buffer: Send,

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

impl<T, U> Send for ZipLongest<T, U>
where T: Send, U: Send,

impl Send for Buffer

impl Send for Algorithm

impl Send for ErrorKind

impl Send for RSAKeyType

impl Send for Error

impl Send for Jwk

impl Send for JwkSet

impl Send for DecodingKey

impl Send for EncodingKey

impl Send for Header

impl Send for Validation

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

impl Send for Error

impl Send for HeaderType

impl Send for Claims

impl Send for Header

impl Send for Signed

impl Send for Unsigned

impl Send for Verified

impl<'a> Send for Unverified<'a>

impl<H, C, S> Send for Token<H, C, S>
where H: Send, C: Send, S: Send,

impl Send for Compression

impl Send for FetchOffset

impl Send for Error

impl Send for KafkaCode

impl Send for Response

impl Send for Broker

impl Send for KafkaClient

impl Send for Builder

impl Send for Consumer

impl Send for MessageSets

impl Send for Partitions

impl<'a> Send for Data<'a>

impl<'a> Send for Message<'a>

impl<'a> Send for Partition<'a>

impl<'a> Send for Topic<'a>

impl<'a> Send for Partition<'a>

impl<'a> Send for PartitionIter<'a>

impl<'a> Send for Partitions<'a>

impl<'a> Send for Topic<'a>

impl<'a> Send for TopicIter<'a>

impl<'a> Send for TopicNames<'a>

impl<'a> Send for Topics<'a>

impl<'a> Send for CommitOffset<'a>

impl<'a> Send for FetchGroupOffset<'a>

impl<'a> Send for FetchPartition<'a>

impl<'a> Send for MessageSet<'a>

impl<'a> Send for MessageSetsIter<'a>

impl<'a> Send for Topics<'a>

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

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

impl<H> Send for DefaultPartitioner<H>
where H: Send,

impl<P> Send for Builder<P>
where P: Send,

impl<P> Send for Producer<P>
where P: Send,

impl Send for Error

impl Send for OverflowVar

impl<const N: usize> Send for Overflow<N>

impl Send for Error

impl !Send for Dl_info

impl !Send for addrinfo

impl !Send for aiocb

impl !Send for dl_phdr_info

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 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 iwreq_data

impl Send for DIR

impl Send for FILE

impl Send for timezone

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 __timeval

impl Send for af_alg_iv

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 dirent

impl Send for dirent64

impl Send for dmabuf_cmsg

impl Send for dqblk

impl Send for epoll_event

impl Send for fanout_args

impl Send for fd_set

impl Send for ff_effect

impl Send for ff_envelope

impl Send for ff_replay

impl Send for ff_trigger

impl Send for flock

impl Send for flock64

impl Send for fpos64_t

impl Send for fpos_t

impl Send for fsid_t

impl Send for genlmsghdr

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 input_event

impl Send for input_id

impl Send for input_mask

impl Send for iocb

impl Send for ip_mreq

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_freq

impl Send for iw_missed

impl Send for iw_mlme

impl Send for iw_param

impl Send for iw_pmksa

impl Send for iw_quality

impl Send for iw_range

impl Send for iw_scan_req

impl Send for iw_thrspy

impl Send for linger

impl Send for mallinfo

impl Send for mallinfo2

impl Send for max_align_t

impl Send for mbstate_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 regmatch_t

impl Send for rlimit

impl Send for rlimit64

impl Send for rusage

impl Send for sched_attr

impl Send for sched_param

impl Send for sctp_prinfo

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 sigset_t

impl Send for sock_filter

impl Send for sock_txtime

impl Send for sockaddr

impl Send for sockaddr_in

impl Send for sockaddr_ll

impl Send for sockaddr_nl

impl Send for sockaddr_un

impl Send for sockaddr_vm

impl Send for stat

impl Send for stat64

impl Send for statfs

impl Send for statfs64

impl Send for statvfs

impl Send for statvfs64

impl Send for statx

impl Send for sysinfo

impl Send for tcp_info

impl Send for termios

impl Send for termios2

impl Send for timespec

impl Send for timeval

impl Send for timex

impl Send for tms

impl Send for tpacket_hdr

impl Send for tpacket_req

impl Send for ucred

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_options

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

impl !Send for Elf_auxv_t

impl !Send for iovec

impl !Send for robust_list

impl !Send for sigaltstack

impl !Send for sigevent

impl !Send for siginfo

impl !Send for group_filter

impl !Send for group_req

impl !Send for if_settings

impl !Send for ifconf

impl !Send for ifreq

impl !Send for ip6t_error

impl !Send for ip6t_replace

impl !Send for mmsghdr

impl !Send for msghdr

impl !Send for sockaddr

impl !Send for tcp_ao_add

impl !Send for tcp_ao_del

impl !Send for tcp_md5sig

impl !Send for prctl_mm_map

impl !Send for __sifields

impl !Send for sigval

impl Send for ipvlan_mode

impl Send for netkit_mode

impl Send for rt_class_t

impl Send for rt_scope_t

impl Send for Elf_Dyn

impl Send for Elf_Ehdr

impl Send for Elf_Phdr

impl Send for Elf_Rel

impl Send for Elf_Rela

impl Send for Elf_Sym

impl Send for Elf_Verdaux

impl Send for Elf_Verdef

impl Send for cachestat

impl Send for clone_args

impl Send for dmabuf_cmsg

impl Send for epoll_event

impl Send for f_owner_ex

impl Send for flock

impl Send for flock64

impl Send for fscrypt_key

impl Send for fsuuid2

impl Send for fsxattr

impl Send for futex_waitv

impl Send for itimerspec

impl Send for itimerval

impl Send for ktermios

impl Send for mnt_id_req

impl Send for mount_attr

impl Send for open_how

impl Send for page_region

impl Send for pm_scan_arg

impl Send for pollfd

impl Send for rlimit

impl Send for rlimit64

impl Send for rusage

impl Send for sigaction

impl Send for stat

impl Send for statfs

impl Send for statfs64

impl Send for statmount

impl Send for statx

impl Send for termio

impl Send for termios

impl Send for termios2

impl Send for timespec

impl Send for timeval

impl Send for timezone

impl Send for uffd_msg

impl Send for uffdio_api

impl Send for uffdio_copy

impl Send for uffdio_move

impl Send for user_desc

impl Send for winsize

impl Send for xattr_args

impl Send for ethhdr

impl Send for _xt_align

impl Send for cisco_proto

impl Send for cmsghdr

impl Send for fr_proto

impl Send for ifmap

impl Send for in6_addr

impl Send for in6_ifreq

impl Send for in6_pktinfo

impl Send for in_addr

impl Send for in_pktinfo

impl Send for iovec

impl Send for ip6_mtuinfo

impl Send for ip6t_entry

impl Send for ip6t_icmp

impl Send for ip6t_ip6

impl Send for ip_auth_hdr

impl Send for ip_comp_hdr

impl Send for ip_esp_hdr

impl Send for ip_mreq

impl Send for ip_mreqn

impl Send for ip_msfilter

impl Send for iphdr

impl Send for ipv6_mreq

impl Send for ipv6_rt_hdr

impl Send for ipv6hdr

impl Send for linger

impl Send for rt0_hdr

impl Send for rt2_hdr

impl Send for sock_txtime

impl Send for sockaddr_in

impl Send for sockaddr_un

impl Send for tcp_info

impl Send for tcphdr

impl Send for ucred

impl Send for xt_counters

impl Send for xt_match

impl Send for xt_target

impl Send for xt_tcp

impl Send for xt_udp

impl Send for ifaddrmsg

impl Send for ifinfomsg

impl Send for ifla_vf_mac

impl Send for ndmsg

impl Send for ndt_config

impl Send for ndt_stats

impl Send for ndtmsg

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 prefixmsg

impl Send for rta_session

impl Send for rtattr

impl Send for rtgenmsg

impl Send for rtmsg

impl Send for rtnexthop

impl Send for rtvia

impl Send for sockaddr_nl

impl Send for tcamsg

impl Send for tcmsg

impl Send for tunnel_msg

impl Send for xdp_desc

impl Send for xdp_options

impl<Storage> Send for __BindgenBitfieldUnit<Storage>
where Storage: Send,

impl<Storage> Send for __BindgenBitfieldUnit<Storage>
where Storage: Send,

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

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

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

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

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

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

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

impl<K, V, S> Send for LiteMap<K, V, S>
where S: Send, K: Send + ?Sized, V: Send + ?Sized,

impl !Send for GuardNoSend

impl Send for GuardSend

impl<'a, R, G, T> !Send for MappedReentrantMutexGuard<'a, R, G, T>

impl<'a, R, G, T> !Send for ReentrantMutexGuard<'a, R, G, T>

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

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

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

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

impl Send for Level

impl Send for LevelFilter

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

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

impl<'a> Send for Metadata<'a>

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

impl<K, V> Send for IntoIter<K, V>
where K: Send, V: Send,

impl<'a, S, A> Send for Matcher<'a, S, A>
where A: Send, S: Send,

impl<S, A> Send for Pattern<S, A>
where A: Send,

impl Send for InsertError

impl Send for MatchError

impl<'k, 'v> Send for Params<'k, 'v>

impl<'k, 'v, V> Send for Match<'k, 'v, V>
where V: Send,

impl<'ps, 'k, 'v> Send for ParamsIter<'ps, 'k, 'v>

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

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

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

impl Send for Md5Core

impl Send for One

impl Send for Three

impl Send for Two

impl Send for Finder

impl Send for Pair

impl Send for Finder

impl Send for FinderRev

impl Send for Finder

impl Send for Finder

impl Send for FinderRev

impl Send for One

impl Send for Three

impl Send for Two

impl Send for Finder

impl Send for One

impl Send for Three

impl Send for Two

impl Send for Finder

impl<'a, 'h> Send for OneIter<'a, 'h>

impl<'a, 'h> Send for ThreeIter<'a, 'h>

impl<'a, 'h> Send for TwoIter<'a, 'h>

impl<'a, 'h> Send for OneIter<'a, 'h>

impl<'a, 'h> Send for ThreeIter<'a, 'h>

impl<'a, 'h> Send for TwoIter<'a, 'h>

impl<'a, 'h> Send for OneIter<'a, 'h>

impl<'a, 'h> Send for ThreeIter<'a, 'h>

impl<'a, 'h> Send for TwoIter<'a, 'h>

impl<'h> Send for Memchr<'h>

impl<'h> Send for Memchr2<'h>

impl<'h> Send for Memchr3<'h>

impl<'h, 'n> Send for FindIter<'h, 'n>

impl<'h, 'n> Send for FindRevIter<'h, 'n>

impl<'n> Send for Finder<'n>

impl<'n> Send for FinderRev<'n>

impl Send for Error

impl Send for FileSeal

impl Send for HugetlbSize

impl Send for Memfd

impl Send for Mime

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

impl<'a> Send for Name<'a>

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

impl Send for TDEFLFlush

impl Send for TDEFLStatus

impl Send for DataFormat

impl Send for MZError

impl Send for MZFlush

impl Send for MZStatus

impl Send for TINFLStatus

impl Send for FullReset

impl Send for MinReset

impl Send for ZeroReset

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

impl Send for Event

impl Send for Events

impl Send for TcpListener

impl Send for TcpStream

impl Send for UdpSocket

impl Send for UnixStream

impl Send for Interest

impl Send for Poll

impl Send for Registry

impl Send for Token

impl Send for Waker

impl Send for Receiver

impl Send for Sender

impl<'a> Send for Iter<'a>

impl<'a> Send for SourceFd<'a>

impl Send for Name

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

impl Send for KeyPairType

impl Send for ErrorKind

impl Send for Error

impl Send for KeyPair

impl Send for XKey

impl Send for Needed

impl Send for ErrorKind

impl Send for Endianness

impl<E> Send for Err<E>
where E: Send,

impl<F, G> Send for And<F, G>
where F: Send, G: Send,

impl<F, G> Send for Or<F, G>
where F: Send, G: Send,

impl<F, G, O1> Send for AndThen<F, G, O1>
where F: Send, G: Send, O1: Send,

impl<F, G, O1> Send for FlatMap<F, G, O1>
where F: Send, G: Send, O1: Send,

impl<F, G, O1> Send for Map<F, G, O1>
where F: Send, G: Send, O1: Send,

impl<F, O1, O2, E1, E2> Send for Into<F, O1, O2, E1, E2>
where F: Send, O1: Send, E1: Send, O2: Send, E2: Send,

impl<I> Send for Error<I>
where I: Send,

impl<I> Send for VerboseError<I>
where I: Send,

impl<I, E, F> Send for ParserIterator<I, E, F>
where F: Send, I: Send, E: Send,

impl Send for Color

impl Send for Infix

impl Send for Prefix

impl Send for Suffix

impl Send for Gradient

impl Send for Rgb

impl Send for Style

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

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

impl Send for NUID

impl Send for NUIDStr

impl Send for Sign

impl Send for BigInt

impl Send for BigUint

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

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

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

impl<E> Send for ParseComplexError<E>
where E: Send,

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

impl<A> Send for ExtendedGcd<A>
where A: Send,

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

impl<A> Send for Range<A>
where A: Send,

impl<A> Send for RangeFrom<A>
where A: Send,

impl<A> Send for RangeInclusive<A>
where A: Send,

impl<A> Send for RangeStep<A>
where A: Send,

impl<A> Send for RangeStepFrom<A>
where A: Send,

impl<A> Send for RangeStepInclusive<A>
where A: Send,

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

impl Send for Endianness

impl Send for AddressSize

impl Send for ComdatKind

impl Send for FileFlags

impl Send for SectionKind

impl Send for SymbolKind

impl Send for SymbolScope

impl Send for ImportType

impl Send for FileKind

impl Send for ObjectKind

impl Send for Name

impl Send for Mangling

impl Send for Ident

impl Send for BigEndian

impl Send for FatArch32

impl Send for FatArch64

impl Send for FatHeader

impl Send for Guid

impl Send for ImageSymbol

impl Send for Relocation

impl Send for Error

impl Send for Relocation

impl Send for SymbolIndex

impl Send for FileHeader

impl Send for Relocation

impl Send for Symbol

impl Send for Class

impl Send for FileHeader

impl Send for Rel

impl Send for Sym

impl Send for SymbolIndex

impl Send for Verdef

impl Send for Vernaux

impl Send for Verneed

impl Send for NtHeaders

impl Send for Section

impl Send for Comdat

impl Send for ComdatId

impl Send for Error

impl Send for Relocation

impl Send for SectionId

impl Send for StringId

impl Send for Symbol

impl Send for SymbolId

impl Send for AuxHeader32

impl Send for AuxHeader64

impl Send for BlockAux32

impl Send for BlockAux64

impl Send for CsectAux32

impl Send for CsectAux64

impl Send for DwarfAux32

impl Send for DwarfAux64

impl Send for ExpAux

impl Send for FileAux32

impl Send for FileAux64

impl Send for FunAux32

impl Send for FunAux64

impl Send for Rel32

impl Send for Rel64

impl Send for StatAux

impl Send for Symbol32

impl Send for Symbol64

impl Send for SymbolBytes

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

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

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

impl<'a> Send for Object<'a>

impl<'a> Send for Section<'a>

impl<'a, R> !Send for ReadCacheRange<'a, R>

impl<'data> Send for ImportName<'data>

impl<'data> Send for ExportTarget<'data>

impl<'data> Send for Import<'data>

impl<'data> Send for ResourceDirectoryEntryData<'data>

impl<'data> Send for ImportFile<'data>

impl<'data> Send for ImportObjectData<'data>

impl<'data> Send for SectionTable<'data>

impl<'data> Send for AttributeIndexIterator<'data>

impl<'data> Send for AttributeReader<'data>

impl<'data> Send for AttributesSubsubsection<'data>

impl<'data> Send for GnuProperty<'data>

impl<'data> Send for Version<'data>

impl<'data> Send for DataDirectories<'data>

impl<'data> Send for DelayLoadDescriptorIterator<'data>

impl<'data> Send for DelayLoadImportTable<'data>

impl<'data> Send for Export<'data>

impl<'data> Send for ExportTable<'data>

impl<'data> Send for ImportDescriptorIterator<'data>

impl<'data> Send for ImportTable<'data>

impl<'data> Send for ImportThunkList<'data>

impl<'data> Send for RelocationBlockIterator<'data>

impl<'data> Send for RelocationIterator<'data>

impl<'data> Send for ResourceDirectory<'data>

impl<'data> Send for ResourceDirectoryTable<'data>

impl<'data> Send for RichHeaderInfo<'data>

impl<'data> Send for Bytes<'data>

impl<'data> Send for CodeView<'data>

impl<'data> Send for CompressedData<'data>

impl<'data> Send for Export<'data>

impl<'data> Send for Import<'data>

impl<'data> Send for ObjectMap<'data>

impl<'data> Send for ObjectMapEntry<'data>

impl<'data> Send for ObjectMapFile<'data>

impl<'data> Send for SymbolMapName<'data>

impl<'data, 'cache, E, R> Send for DyldCacheImage<'data, 'cache, E, R>
where E: Sync, R: Sync,

impl<'data, 'cache, E, R> Send for DyldCacheImageIterator<'data, 'cache, E, R>
where E: Sync, R: Sync,

impl<'data, 'file, Elf, R> Send for ElfComdat<'data, 'file, Elf, R>
where <Elf as FileHeader>::SectionHeader: Sync, <Elf as FileHeader>::Endian: Sync, R: Sync, Elf: Sync, <Elf as FileHeader>::ProgramHeader: Sync, <Elf as FileHeader>::Sym: Sync,

impl<'data, 'file, Elf, R> Send for ElfComdatIterator<'data, 'file, Elf, R>
where <Elf as FileHeader>::Endian: Sync, R: Sync, <Elf as FileHeader>::SectionHeader: Sync, Elf: Sync, <Elf as FileHeader>::ProgramHeader: Sync, <Elf as FileHeader>::Sym: Sync,

impl<'data, 'file, Elf, R> Send for ElfComdatSectionIterator<'data, 'file, Elf, R>
where <Elf as FileHeader>::Endian: Sync, R: Sync, Elf: Sync, <Elf as FileHeader>::ProgramHeader: Sync, <Elf as FileHeader>::SectionHeader: Sync, <Elf as FileHeader>::Sym: Sync,

impl<'data, 'file, Elf, R> Send for ElfDynamicRelocationIterator<'data, 'file, Elf, R>
where <Elf as FileHeader>::Endian: Sync, R: Sync, Elf: Sync, <Elf as FileHeader>::Rel: Sync, <Elf as FileHeader>::Rela: Sync, <Elf as FileHeader>::ProgramHeader: Sync, <Elf as FileHeader>::SectionHeader: Sync, <Elf as FileHeader>::Sym: Sync,

impl<'data, 'file, Elf, R> Send for ElfSection<'data, 'file, Elf, R>
where <Elf as FileHeader>::SectionHeader: Sync, <Elf as FileHeader>::Endian: Sync, R: Sync, Elf: Sync, <Elf as FileHeader>::ProgramHeader: Sync, <Elf as FileHeader>::Sym: Sync,

impl<'data, 'file, Elf, R> Send for ElfSectionIterator<'data, 'file, Elf, R>
where <Elf as FileHeader>::Endian: Sync, R: Sync, <Elf as FileHeader>::SectionHeader: Sync, Elf: Sync, <Elf as FileHeader>::ProgramHeader: Sync, <Elf as FileHeader>::Sym: Sync,

impl<'data, 'file, Elf, R> Send for ElfSectionRelocationIterator<'data, 'file, Elf, R>
where <Elf as FileHeader>::Endian: Sync, R: Sync, Elf: Sync, <Elf as FileHeader>::Rel: Sync, <Elf as FileHeader>::Rela: Sync, <Elf as FileHeader>::ProgramHeader: Sync, <Elf as FileHeader>::SectionHeader: Sync, <Elf as FileHeader>::Sym: Sync,

impl<'data, 'file, Elf, R> Send for ElfSegment<'data, 'file, Elf, R>
where <Elf as FileHeader>::ProgramHeader: Sync, <Elf as FileHeader>::Endian: Sync, R: Sync, Elf: Sync, <Elf as FileHeader>::SectionHeader: Sync, <Elf as FileHeader>::Sym: Sync,

impl<'data, 'file, Elf, R> Send for ElfSegmentIterator<'data, 'file, Elf, R>
where <Elf as FileHeader>::ProgramHeader: Sync, <Elf as FileHeader>::Endian: Sync, R: Sync, Elf: Sync, <Elf as FileHeader>::SectionHeader: Sync, <Elf as FileHeader>::Sym: Sync,

impl<'data, 'file, Elf, R> Send for ElfSymbol<'data, 'file, Elf, R>
where <Elf as FileHeader>::Endian: Send + Sync, <Elf as FileHeader>::Sym: Sync, R: Sync,

impl<'data, 'file, Elf, R> Send for ElfSymbolIterator<'data, 'file, Elf, R>
where <Elf as FileHeader>::Endian: Send + Sync, <Elf as FileHeader>::Sym: Sync, R: Sync,

impl<'data, 'file, Elf, R> Send for ElfSymbolTable<'data, 'file, Elf, R>
where <Elf as FileHeader>::Endian: Send + Sync, <Elf as FileHeader>::Sym: Sync, R: Sync,

impl<'data, 'file, Mach, R> Send for MachOComdat<'data, 'file, Mach, R>
where <Mach as MachHeader>::Endian: Sync, R: Sync, Mach: Sync, <Mach as MachHeader>::Nlist: Sync, <Mach as MachHeader>::Segment: Sync, <Mach as MachHeader>::Section: Sync,

impl<'data, 'file, Mach, R> Send for MachOComdatIterator<'data, 'file, Mach, R>
where <Mach as MachHeader>::Endian: Sync, R: Sync, Mach: Sync, <Mach as MachHeader>::Nlist: Sync, <Mach as MachHeader>::Segment: Sync, <Mach as MachHeader>::Section: Sync,

impl<'data, 'file, Mach, R> Send for MachOComdatSectionIterator<'data, 'file, Mach, R>
where <Mach as MachHeader>::Endian: Sync, R: Sync, Mach: Sync, <Mach as MachHeader>::Nlist: Sync, <Mach as MachHeader>::Segment: Sync, <Mach as MachHeader>::Section: Sync,

impl<'data, 'file, Mach, R> Send for MachORelocationIterator<'data, 'file, Mach, R>
where <Mach as MachHeader>::Endian: Sync, R: Sync, Mach: Sync, <Mach as MachHeader>::Nlist: Sync, <Mach as MachHeader>::Segment: Sync, <Mach as MachHeader>::Section: Sync,

impl<'data, 'file, Mach, R> Send for MachOSection<'data, 'file, Mach, R>
where R: Send + Sync, <Mach as MachHeader>::Endian: Sync, <Mach as MachHeader>::Section: Sync, Mach: Sync, <Mach as MachHeader>::Nlist: Sync, <Mach as MachHeader>::Segment: Sync,

impl<'data, 'file, Mach, R> Send for MachOSectionIterator<'data, 'file, Mach, R>
where <Mach as MachHeader>::Endian: Sync, R: Sync, Mach: Sync, <Mach as MachHeader>::Section: Sync, <Mach as MachHeader>::Nlist: Sync, <Mach as MachHeader>::Segment: Sync,

impl<'data, 'file, Mach, R> Send for MachOSegment<'data, 'file, Mach, R>
where <Mach as MachHeader>::Endian: Sync, R: Sync, Mach: Sync, <Mach as MachHeader>::Segment: Sync, <Mach as MachHeader>::Nlist: Sync, <Mach as MachHeader>::Section: Sync,

impl<'data, 'file, Mach, R> Send for MachOSegmentIterator<'data, 'file, Mach, R>
where <Mach as MachHeader>::Endian: Sync, R: Sync, Mach: Sync, <Mach as MachHeader>::Segment: Sync, <Mach as MachHeader>::Nlist: Sync, <Mach as MachHeader>::Section: Sync,

impl<'data, 'file, Mach, R> Send for MachOSymbol<'data, 'file, Mach, R>
where <Mach as MachHeader>::Nlist: Sync, <Mach as MachHeader>::Endian: Sync, R: Sync, Mach: Sync, <Mach as MachHeader>::Segment: Sync, <Mach as MachHeader>::Section: Sync,

impl<'data, 'file, Mach, R> Send for MachOSymbolIterator<'data, 'file, Mach, R>
where <Mach as MachHeader>::Endian: Sync, R: Sync, Mach: Sync, <Mach as MachHeader>::Nlist: Sync, <Mach as MachHeader>::Segment: Sync, <Mach as MachHeader>::Section: Sync,

impl<'data, 'file, Mach, R> Send for MachOSymbolTable<'data, 'file, Mach, R>
where <Mach as MachHeader>::Endian: Sync, R: Sync, Mach: Sync, <Mach as MachHeader>::Nlist: Sync, <Mach as MachHeader>::Segment: Sync, <Mach as MachHeader>::Section: Sync,

impl<'data, 'file, Pe, R> Send for PeComdat<'data, 'file, Pe, R>
where R: Sync, Pe: Sync,

impl<'data, 'file, Pe, R> Send for PeComdatIterator<'data, 'file, Pe, R>
where R: Sync, Pe: Sync,

impl<'data, 'file, Pe, R> Send for PeComdatSectionIterator<'data, 'file, Pe, R>
where R: Sync, Pe: Sync,

impl<'data, 'file, Pe, R> Send for PeSection<'data, 'file, Pe, R>
where R: Sync, Pe: Sync,

impl<'data, 'file, Pe, R> Send for PeSectionIterator<'data, 'file, Pe, R>
where R: Sync, Pe: Sync,

impl<'data, 'file, Pe, R> Send for PeSegment<'data, 'file, Pe, R>
where R: Sync, Pe: Sync,

impl<'data, 'file, Pe, R> Send for PeSegmentIterator<'data, 'file, Pe, R>
where R: Sync, Pe: Sync,

impl<'data, 'file, R> Send for PeRelocationIterator<'data, 'file, R>
where R: Send,

impl<'data, 'file, R> Send for Comdat<'data, 'file, R>
where R: Sync,

impl<'data, 'file, R> Send for ComdatIterator<'data, 'file, R>
where R: Sync,

impl<'data, 'file, R> Send for ComdatSectionIterator<'data, 'file, R>
where R: Sync,

impl<'data, 'file, R> Send for DynamicRelocationIterator<'data, 'file, R>
where R: Send + Sync,

impl<'data, 'file, R> Send for Section<'data, 'file, R>
where R: Send + Sync,

impl<'data, 'file, R> Send for SectionIterator<'data, 'file, R>
where R: Sync,

impl<'data, 'file, R> Send for SectionRelocationIterator<'data, 'file, R>
where R: Sync + Send,

impl<'data, 'file, R> Send for Segment<'data, 'file, R>
where R: Sync,

impl<'data, 'file, R> Send for SegmentIterator<'data, 'file, R>
where R: Sync,

impl<'data, 'file, R> Send for Symbol<'data, 'file, R>
where R: Send + Sync,

impl<'data, 'file, R> Send for SymbolIterator<'data, 'file, R>
where R: Send + Sync,

impl<'data, 'file, R> Send for SymbolTable<'data, 'file, R>
where R: Send + Sync,

impl<'data, 'file, R, Coff> Send for CoffComdat<'data, 'file, R, Coff>
where <Coff as CoffHeader>::ImageSymbol: Sync, R: Sync, Coff: Sync, <Coff as CoffHeader>::ImageSymbolBytes: Sync,

impl<'data, 'file, R, Coff> Send for CoffComdatIterator<'data, 'file, R, Coff>
where R: Sync, Coff: Sync, <Coff as CoffHeader>::ImageSymbolBytes: Sync,

impl<'data, 'file, R, Coff> Send for CoffComdatSectionIterator<'data, 'file, R, Coff>
where R: Sync, Coff: Sync, <Coff as CoffHeader>::ImageSymbolBytes: Sync,

impl<'data, 'file, R, Coff> Send for CoffRelocationIterator<'data, 'file, R, Coff>
where R: Sync, Coff: Sync, <Coff as CoffHeader>::ImageSymbolBytes: Sync,

impl<'data, 'file, R, Coff> Send for CoffSection<'data, 'file, R, Coff>
where R: Sync, Coff: Sync, <Coff as CoffHeader>::ImageSymbolBytes: Sync,

impl<'data, 'file, R, Coff> Send for CoffSectionIterator<'data, 'file, R, Coff>
where R: Sync, Coff: Sync, <Coff as CoffHeader>::ImageSymbolBytes: Sync,

impl<'data, 'file, R, Coff> Send for CoffSegment<'data, 'file, R, Coff>
where R: Sync, Coff: Sync, <Coff as CoffHeader>::ImageSymbolBytes: Sync,

impl<'data, 'file, R, Coff> Send for CoffSegmentIterator<'data, 'file, R, Coff>
where R: Sync, Coff: Sync, <Coff as CoffHeader>::ImageSymbolBytes: Sync,

impl<'data, 'file, R, Coff> Send for CoffSymbol<'data, 'file, R, Coff>
where <Coff as CoffHeader>::ImageSymbol: Sync, <Coff as CoffHeader>::ImageSymbolBytes: Sync, R: Sync,

impl<'data, 'file, R, Coff> Send for CoffSymbolIterator<'data, 'file, R, Coff>
where <Coff as CoffHeader>::ImageSymbolBytes: Sync, R: Sync,

impl<'data, 'file, R, Coff> Send for CoffSymbolTable<'data, 'file, R, Coff>
where <Coff as CoffHeader>::ImageSymbolBytes: Sync, R: Sync,

impl<'data, 'file, Xcoff, R> Send for XcoffComdat<'data, 'file, Xcoff, R>
where R: Sync, Xcoff: Sync, <Xcoff as FileHeader>::AuxHeader: Sync, <Xcoff as FileHeader>::SectionHeader: Sync,

impl<'data, 'file, Xcoff, R> Send for XcoffComdatIterator<'data, 'file, Xcoff, R>
where R: Sync, Xcoff: Sync, <Xcoff as FileHeader>::AuxHeader: Sync, <Xcoff as FileHeader>::SectionHeader: Sync,

impl<'data, 'file, Xcoff, R> Send for XcoffComdatSectionIterator<'data, 'file, Xcoff, R>
where R: Sync, Xcoff: Sync, <Xcoff as FileHeader>::AuxHeader: Sync, <Xcoff as FileHeader>::SectionHeader: Sync,

impl<'data, 'file, Xcoff, R> Send for XcoffRelocationIterator<'data, 'file, Xcoff, R>
where <Xcoff as FileHeader>::Rel: Sync, R: Sync, Xcoff: Sync, <Xcoff as FileHeader>::AuxHeader: Sync, <Xcoff as FileHeader>::SectionHeader: Sync,

impl<'data, 'file, Xcoff, R> Send for XcoffSection<'data, 'file, Xcoff, R>
where <Xcoff as FileHeader>::SectionHeader: Sync, R: Sync, Xcoff: Sync, <Xcoff as FileHeader>::AuxHeader: Sync,

impl<'data, 'file, Xcoff, R> Send for XcoffSectionIterator<'data, 'file, Xcoff, R>
where R: Sync, <Xcoff as FileHeader>::SectionHeader: Sync, Xcoff: Sync, <Xcoff as FileHeader>::AuxHeader: Sync,

impl<'data, 'file, Xcoff, R> Send for XcoffSegment<'data, 'file, Xcoff, R>
where R: Sync, Xcoff: Sync, <Xcoff as FileHeader>::AuxHeader: Sync, <Xcoff as FileHeader>::SectionHeader: Sync,

impl<'data, 'file, Xcoff, R> Send for XcoffSegmentIterator<'data, 'file, Xcoff, R>
where R: Sync, Xcoff: Sync, <Xcoff as FileHeader>::AuxHeader: Sync, <Xcoff as FileHeader>::SectionHeader: Sync,

impl<'data, 'file, Xcoff, R> Send for XcoffSymbol<'data, 'file, Xcoff, R>
where <Xcoff as FileHeader>::Symbol: Sync, R: Sync, Xcoff: Sync, <Xcoff as FileHeader>::AuxHeader: Sync, <Xcoff as FileHeader>::SectionHeader: Sync,

impl<'data, 'file, Xcoff, R> Send for XcoffSymbolIterator<'data, 'file, Xcoff, R>
where R: Sync, Xcoff: Sync, <Xcoff as FileHeader>::AuxHeader: Sync, <Xcoff as FileHeader>::SectionHeader: Sync,

impl<'data, 'file, Xcoff, R> Send for XcoffSymbolTable<'data, 'file, Xcoff, R>
where R: Sync, Xcoff: Sync, <Xcoff as FileHeader>::AuxHeader: Sync, <Xcoff as FileHeader>::SectionHeader: Sync,

impl<'data, 'table, R, Coff> Send for SymbolIterator<'data, 'table, R, Coff>
where <Coff as CoffHeader>::ImageSymbolBytes: Sync, R: Sync,

impl<'data, 'table, Xcoff, R> Send for SymbolIterator<'data, 'table, Xcoff, R>
where Xcoff: Sync, R: Sync,

impl<'data, E> Send for DyldSubCacheSlice<'data, E>
where E: Sync,

impl<'data, E> Send for LoadCommandVariant<'data, E>
where E: Sync,

impl<'data, E> Send for LoadCommandData<'data, E>
where E: Send,

impl<'data, E> Send for LoadCommandIterator<'data, E>
where E: Send,

impl<'data, E, R> Send for DyldCache<'data, E, R>
where E: Send + Sync, R: Send,

impl<'data, E, R> Send for DyldSubCache<'data, E, R>
where R: Send, E: Sync,

impl<'data, Elf> Send for AttributesSection<'data, Elf>
where <Elf as FileHeader>::Endian: Send,

impl<'data, Elf> Send for AttributesSubsection<'data, Elf>
where <Elf as FileHeader>::Endian: Send,

impl<'data, Elf> Send for AttributesSubsectionIterator<'data, Elf>
where <Elf as FileHeader>::Endian: Send,

impl<'data, Elf> Send for AttributesSubsubsectionIterator<'data, Elf>
where <Elf as FileHeader>::Endian: Send,

impl<'data, Elf> Send for GnuHashTable<'data, Elf>
where <Elf as FileHeader>::Endian: Sync,

impl<'data, Elf> Send for HashTable<'data, Elf>
where <Elf as FileHeader>::Endian: Sync,

impl<'data, Elf> Send for Note<'data, Elf>
where <Elf as FileHeader>::NoteHeader: Sync,

impl<'data, Elf> Send for NoteIterator<'data, Elf>
where <Elf as FileHeader>::Endian: Send,

impl<'data, Elf> Send for RelrIterator<'data, Elf>
where <Elf as FileHeader>::Word: Send, <Elf as FileHeader>::Endian: Send, <Elf as FileHeader>::Relr: Sync,

impl<'data, Elf> Send for VerdauxIterator<'data, Elf>
where <Elf as FileHeader>::Endian: Send,

impl<'data, Elf> Send for VerdefIterator<'data, Elf>
where <Elf as FileHeader>::Endian: Send,

impl<'data, Elf> Send for VernauxIterator<'data, Elf>
where <Elf as FileHeader>::Endian: Send,

impl<'data, Elf> Send for VerneedIterator<'data, Elf>
where <Elf as FileHeader>::Endian: Send,

impl<'data, Elf> Send for VersionTable<'data, Elf>
where <Elf as FileHeader>::Endian: Sync,

impl<'data, Elf, R> Send for ElfFile<'data, Elf, R>
where <Elf as FileHeader>::Endian: Send + Sync, R: Send, Elf: Sync, <Elf as FileHeader>::ProgramHeader: Sync, <Elf as FileHeader>::SectionHeader: Sync, <Elf as FileHeader>::Sym: Sync,

impl<'data, Elf, R> Send for SectionTable<'data, Elf, R>
where <Elf as FileHeader>::SectionHeader: Sync, R: Send,

impl<'data, Elf, R> Send for SymbolTable<'data, Elf, R>
where <Elf as FileHeader>::Sym: Sync, R: Send, <Elf as FileHeader>::Endian: Sync,

impl<'data, Endian> Send for GnuPropertyIterator<'data, Endian>
where Endian: Send,

impl<'data, Fat> Send for MachOFatFile<'data, Fat>
where Fat: Sync,

impl<'data, Mach, R> Send for MachOFile<'data, Mach, R>
where <Mach as MachHeader>::Endian: Send, R: Send, Mach: Sync, <Mach as MachHeader>::Nlist: Sync, <Mach as MachHeader>::Segment: Sync, <Mach as MachHeader>::Section: Sync,

impl<'data, Mach, R> Send for SymbolTable<'data, Mach, R>
where <Mach as MachHeader>::Nlist: Sync, R: Send,

impl<'data, Pe, R> Send for PeFile<'data, Pe, R>
where R: Send, Pe: Sync,

impl<'data, R> Send for File<'data, R>
where R: Send,

impl<'data, R> Send for StringTable<'data, R>
where R: Send,

impl<'data, R, Coff> Send for CoffFile<'data, R, Coff>
where R: Send, Coff: Sync, <Coff as CoffHeader>::ImageSymbolBytes: Sync,

impl<'data, R, Coff> Send for SymbolTable<'data, R, Coff>
where <Coff as CoffHeader>::ImageSymbolBytes: Sync, R: Send,

impl<'data, Xcoff> Send for SectionTable<'data, Xcoff>
where <Xcoff as FileHeader>::SectionHeader: Sync,

impl<'data, Xcoff, R> Send for SymbolTable<'data, Xcoff, R>
where Xcoff: Send, R: Send,

impl<'data, Xcoff, R> Send for XcoffFile<'data, Xcoff, R>
where R: Send, Xcoff: Sync + Send, <Xcoff as FileHeader>::AuxHeader: Sync, <Xcoff as FileHeader>::SectionHeader: Sync,

impl<E> Send for CompressionHeader32<E>
where E: Send,

impl<E> Send for CompressionHeader64<E>
where E: Send,

impl<E> Send for Dyn32<E>
where E: Send,

impl<E> Send for Dyn64<E>
where E: Send,

impl<E> Send for FileHeader32<E>
where E: Send,

impl<E> Send for FileHeader64<E>
where E: Send,

impl<E> Send for GnuHashHeader<E>
where E: Send,

impl<E> Send for HashHeader<E>
where E: Send,

impl<E> Send for NoteHeader32<E>
where E: Send,

impl<E> Send for NoteHeader64<E>
where E: Send,

impl<E> Send for ProgramHeader32<E>
where E: Send,

impl<E> Send for ProgramHeader64<E>
where E: Send,

impl<E> Send for Rel32<E>
where E: Send,

impl<E> Send for Rel64<E>
where E: Send,

impl<E> Send for Rela32<E>
where E: Send,

impl<E> Send for Rela64<E>
where E: Send,

impl<E> Send for Relr32<E>
where E: Send,

impl<E> Send for Relr64<E>
where E: Send,

impl<E> Send for SectionHeader32<E>
where E: Send,

impl<E> Send for SectionHeader64<E>
where E: Send,

impl<E> Send for Sym32<E>
where E: Send,

impl<E> Send for Sym64<E>
where E: Send,

impl<E> Send for Syminfo32<E>
where E: Send,

impl<E> Send for Syminfo64<E>
where E: Send,

impl<E> Send for Verdaux<E>
where E: Send,

impl<E> Send for Verdef<E>
where E: Send,

impl<E> Send for Vernaux<E>
where E: Send,

impl<E> Send for Verneed<E>
where E: Send,

impl<E> Send for Versym<E>
where E: Send,

impl<E> Send for I16<E>
where E: Send,

impl<E> Send for I16Bytes<E>
where E: Send,

impl<E> Send for I32<E>
where E: Send,

impl<E> Send for I32Bytes<E>
where E: Send,

impl<E> Send for I64<E>
where E: Send,

impl<E> Send for I64Bytes<E>
where E: Send,

impl<E> Send for U16<E>
where E: Send,

impl<E> Send for U16Bytes<E>
where E: Send,

impl<E> Send for U32<E>
where E: Send,

impl<E> Send for U32Bytes<E>
where E: Send,

impl<E> Send for U64<E>
where E: Send,

impl<E> Send for U64Bytes<E>
where E: Send,

impl<E> Send for BuildToolVersion<E>
where E: Send,

impl<E> Send for BuildVersionCommand<E>
where E: Send,

impl<E> Send for DataInCodeEntry<E>
where E: Send,

impl<E> Send for DyldCacheHeader<E>
where E: Send,

impl<E> Send for DyldCacheImageInfo<E>
where E: Send,

impl<E> Send for DyldCacheMappingInfo<E>
where E: Send,

impl<E> Send for DyldInfoCommand<E>
where E: Send,

impl<E> Send for DyldSubCacheEntryV1<E>
where E: Send,

impl<E> Send for DyldSubCacheEntryV2<E>
where E: Send,

impl<E> Send for Dylib<E>
where E: Send,

impl<E> Send for DylibCommand<E>
where E: Send,

impl<E> Send for DylibModule32<E>
where E: Send,

impl<E> Send for DylibModule64<E>
where E: Send,

impl<E> Send for DylibReference<E>
where E: Send,

impl<E> Send for DylibTableOfContents<E>
where E: Send,

impl<E> Send for DylinkerCommand<E>
where E: Send,

impl<E> Send for DysymtabCommand<E>
where E: Send,

impl<E> Send for EncryptionInfoCommand32<E>
where E: Send,

impl<E> Send for EncryptionInfoCommand64<E>
where E: Send,

impl<E> Send for EntryPointCommand<E>
where E: Send,

impl<E> Send for FilesetEntryCommand<E>
where E: Send,

impl<E> Send for FvmfileCommand<E>
where E: Send,

impl<E> Send for Fvmlib<E>
where E: Send,

impl<E> Send for FvmlibCommand<E>
where E: Send,

impl<E> Send for IdentCommand<E>
where E: Send,

impl<E> Send for LcStr<E>
where E: Send,

impl<E> Send for LinkeditDataCommand<E>
where E: Send,

impl<E> Send for LinkerOptionCommand<E>
where E: Send,

impl<E> Send for LoadCommand<E>
where E: Send,

impl<E> Send for MachHeader32<E>
where E: Send,

impl<E> Send for MachHeader64<E>
where E: Send,

impl<E> Send for Nlist32<E>
where E: Send,

impl<E> Send for Nlist64<E>
where E: Send,

impl<E> Send for NoteCommand<E>
where E: Send,

impl<E> Send for PrebindCksumCommand<E>
where E: Send,

impl<E> Send for PreboundDylibCommand<E>
where E: Send,

impl<E> Send for Relocation<E>
where E: Send,

impl<E> Send for RoutinesCommand32<E>
where E: Send,

impl<E> Send for RoutinesCommand64<E>
where E: Send,

impl<E> Send for RpathCommand<E>
where E: Send,

impl<E> Send for Section32<E>
where E: Send,

impl<E> Send for Section64<E>
where E: Send,

impl<E> Send for SegmentCommand32<E>
where E: Send,

impl<E> Send for SegmentCommand64<E>
where E: Send,

impl<E> Send for SourceVersionCommand<E>
where E: Send,

impl<E> Send for SubClientCommand<E>
where E: Send,

impl<E> Send for SubFrameworkCommand<E>
where E: Send,

impl<E> Send for SubLibraryCommand<E>
where E: Send,

impl<E> Send for SubUmbrellaCommand<E>
where E: Send,

impl<E> Send for SymsegCommand<E>
where E: Send,

impl<E> Send for SymtabCommand<E>
where E: Send,

impl<E> Send for ThreadCommand<E>
where E: Send,

impl<E> Send for TwolevelHint<E>
where E: Send,

impl<E> Send for TwolevelHintsCommand<E>
where E: Send,

impl<E> Send for UuidCommand<E>
where E: Send,

impl<E> Send for VersionMinCommand<E>
where E: Send,

impl<R> Send for ReadCache<R>
where R: Send,

impl<Section, Symbol> Send for SymbolFlags<Section, Symbol>
where Section: Send, Symbol: Send,

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

impl<W> Send for StreamingBuffer<W>
where W: Send,

impl Send for Os

impl Send for DigestError

impl Send for OciManifest

impl Send for Certificate

impl Send for Config

impl Send for ImageData

impl Send for ImageLayer

impl Send for SizedStream

impl Send for TagResponse

impl Send for Config

impl Send for ConfigFile

impl Send for History

impl Send for Rootfs

impl Send for OciEnvelope

impl Send for OciError

impl Send for Platform

impl Send for Versioned

impl Send for Client

impl<'a> Send for LayerDescriptor<'a>

impl Send for ErrorCode

impl Send for ParseError

impl Send for Arch

impl Send for MediaType

impl Send for Os

impl Send for Arch

impl Send for Capability

impl Send for ErrorInfo

impl Send for Reference

impl Send for TagList

impl Send for Config

impl Send for Descriptor

impl Send for Digest

impl Send for History

impl Send for ImageIndex

impl Send for OciLayout

impl Send for Platform

impl Send for RootFs

impl Send for Apparmor

impl Send for Box

impl Send for BoxBuilder

impl Send for Cgroup

impl Send for Features

impl Send for Hook

impl Send for HookBuilder

impl Send for Hooks

impl Send for IDMap

impl Send for IntelRdt

impl Send for Linux

impl Send for LinuxCpu

impl Send for LinuxDevice

impl Send for LinuxMemory

impl Send for LinuxPids

impl Send for LinuxRdma

impl Send for Mount

impl Send for PosixRlimit

impl Send for Process

impl Send for Root

impl Send for RootBuilder

impl Send for Scheduler

impl Send for Seccomp

impl Send for Selinux

impl Send for Solaris

impl Send for SolarisAnet

impl Send for Spec

impl Send for SpecBuilder

impl Send for User

impl Send for UserBuilder

impl Send for VM

impl Send for VMBuilder

impl Send for VMImage

impl Send for VMKernel

impl Send for Windows

impl Send for Component

impl Send for WasmClient

impl Send for WasmConfig

impl<'a> Send for AnnotatedWasmConfig<'a>

impl Send for LoadedEntry

impl Send for OidEntry

impl<'a> Send for OidRegistry<'a>

impl Send for OnceBool

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

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

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

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

impl<T, F> Send for Lazy<T, F>
where T: Send, F: Send,

impl<T, F> Send for Lazy<T, F>
where F: Send, T: Send,

impl Send for ProbeResult

impl !Send for ContextGuard

impl Send for Array

impl Send for Value

impl Send for AnyValue

impl Send for Severity

impl Send for SpanKind

impl Send for Status

impl Send for TraceError

impl Send for Baggage

impl Send for BoxedSpan

impl Send for BoxedTracer

impl Send for Meter

impl Send for Context

impl Send for Key

impl Send for KeyValue

impl Send for SpanId

impl Send for StringValue

impl Send for TraceFlags

impl Send for TraceId

impl Send for NoopSpan

impl Send for NoopTracer

impl Send for Event

impl Send for Link

impl Send for SpanBuilder

impl Send for SpanContext

impl Send for TraceState

impl<'a> Send for Iter<'a>

impl<'a> Send for FieldIter<'a>

impl<'a> Send for SpanRef<'a>

impl<'a, I, M> !Send for AsyncInstrumentBuilder<'a, I, M>

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

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

impl<T> Send for Counter<T>

impl<T> Send for Gauge<T>

impl<T> Send for Histogram<T>

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

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

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

impl<T> Send for UpDownCounter<T>

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

impl<P, L> Send for OpenTelemetryTracingBridge<P, L>

impl<'a> Send for HeaderExtractor<'a>

impl<'a> Send for HeaderInjector<'a>

impl<'a> Send for NatsHeaderExtractor<'a>

impl Send for Compression

impl Send for Error

impl Send for Protocol

impl Send for LogExporter

impl Send for TonicConfig

impl Send for Value

impl Send for Value

impl Send for Data

impl Send for Value

impl Send for SpanFlags

impl Send for SpanKind

impl Send for StatusCode

impl Send for AnyValue

impl Send for ArrayValue

impl Send for KeyValue

impl Send for LogRecord

impl Send for LogsData

impl Send for ScopeLogs

impl Send for Buckets

impl Send for Exemplar

impl Send for Gauge

impl Send for Histogram

impl Send for Metric

impl Send for MetricsData

impl Send for Sum

impl Send for Summary

impl Send for Resource

impl Send for Event

impl Send for Link

impl Send for ScopeSpans

impl Send for Span

impl Send for Status

impl Send for TracesData

impl Send for Attributes

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

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

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

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

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

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

impl Send for LogError

impl Send for Aggregation

impl Send for MetricError

impl Send for Temporality

impl Send for Sampler

impl Send for BatchConfig

impl Send for SdkLogger

impl Send for Metric

impl Send for Tokio

impl Send for Resource

impl Send for BatchConfig

impl Send for Config

impl Send for SdkTracer

impl Send for Span

impl Send for SpanData

impl Send for SpanEvents

impl Send for SpanLimits

impl Send for SpanLinks

impl<'a> Send for LogBatch<'a>

impl<'a> Send for Iter<'a>

impl<E> Send for BatchLogProcessorBuilder<E>
where E: Send,

impl<E> Send for PeriodicReaderBuilder<E>
where E: Send,

impl<E, R> Send for BatchLogProcessorBuilder<E, R>
where E: Send, R: Send,

impl<E, R> Send for BatchSpanProcessorBuilder<E, R>
where E: Send, R: Send,

impl<E, RT> Send for PeriodicReaderBuilder<E, RT>
where E: Send, RT: Send,

impl<R> Send for BatchLogProcessor<R>

impl<R> Send for BatchSpanProcessor<R>

impl<T> Send for SimpleLogProcessor<T>

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

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

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

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

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

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

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

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

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

impl Send for Parker

impl Send for Unparker

impl Send for OnceState

impl Send for Condvar

impl Send for Once

impl Send for RawMutex

impl Send for RawRwLock

impl Send for RawThreadId

impl Send for FilterOp

impl Send for ParkResult

impl Send for RequeueOp

impl Send for ParkToken

impl Send for SpinWait

impl Send for UnparkToken

impl Send for LineEnding

impl Send for PemError

impl Send for HeaderMap

impl Send for Pem

impl<'a> Send for HeadersIter<'a>

impl Send for Error

impl<'i> Send for Decoder<'i>

impl<'l, 'o> Send for Encoder<'l, 'o>

impl Send for AsciiSet

impl<'a> Send for PercentDecode<'a>

impl<'a> Send for PercentEncode<'a>

impl Send for PgNumeric

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

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

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

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

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

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

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

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

impl<K, V> Send for Map<K, V>
where K: Sync, V: Sync,

impl<K, V> Send for OrderedMap<K, V>
where K: Sync, V: Sync,

impl<T> Send for OrderedSet<T>
where T: Sync,

impl<T> Send for Set<T>
where T: Sync,

impl Send for Hashes

impl Send for Error

impl Send for Version

impl<'a> Send for PrivateKeyInfo<'a>

impl Send for Poly1305

impl Send for AtomicBool

impl Send for AtomicI128

impl Send for AtomicI16

impl Send for AtomicI32

impl Send for AtomicI64

impl Send for AtomicI8

impl Send for AtomicIsize

impl Send for AtomicU128

impl Send for AtomicU16

impl Send for AtomicU32

impl Send for AtomicU64

impl Send for AtomicU8

impl Send for AtomicUsize

impl<T> Send for AtomicPtr<T>

impl Send for Error

impl Send for AllocVec

impl Send for Size

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

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

impl<'de> !Send for Slice<'de>

impl<'de, F> Send for Deserializer<'de, F>
where F: Send,

impl<'de, T> !Send for IOReader<'de, T>

impl<B> Send for Cobs<B>
where B: Send,

impl<F> Send for Serializer<F>
where F: Send,

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

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

impl<const N: usize> Send for CobsAccumulator<N>

impl Send for Config

impl Send for CancelToken

impl Send for Client

impl<'a> Send for BinaryCopyInWriter<'a>

impl<'a> Send for BinaryCopyOutIter<'a>

impl<'a> Send for BlockingIter<'a>

impl<'a> Send for Iter<'a>

impl<'a> Send for TimeoutIter<'a>

impl<'a> Send for CopyInWriter<'a>

impl<'a> Send for CopyOutReader<'a>

impl<'a> Send for Notifications<'a>

impl<'a> Send for RowIter<'a>

impl<'a> Send for Transaction<'a>

impl<'a> Send for TransactionBuilder<'a>

impl Send for IsNull

impl Send for Message

impl Send for BindError

impl Send for ScramSha256

impl Send for DataRowBody

impl Send for Header

impl Send for Box

impl Send for Inet

impl Send for Point

impl<'a> Send for Range<'a>

impl<'a> Send for ColumnFormats<'a>

impl<'a> Send for DataRowRanges<'a>

impl<'a> Send for ErrorField<'a>

impl<'a> Send for ErrorFields<'a>

impl<'a> Send for Field<'a>

impl<'a> Send for Fields<'a>

impl<'a> Send for Parameters<'a>

impl<'a> Send for SaslMechanisms<'a>

impl<'a> Send for Array<'a>

impl<'a> Send for ArrayDimensions<'a>

impl<'a> Send for ArrayValues<'a>

impl<'a> Send for HstoreEntries<'a>

impl<'a> Send for Path<'a>

impl<'a> Send for PathPoints<'a>

impl<'a> Send for Varbit<'a>

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

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

impl Send for Format

impl Send for IsNull

impl Send for Kind

impl Send for Field

impl Send for PgLsn

impl Send for Type

impl Send for WasNull

impl Send for WrongType

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

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

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

impl<'a, T> Send for Metadata<'a, T>
where <T as SmartDisplay>::Metadata: Send, T: Sync + ?Sized,

impl<const SIZE: usize> Send for WriteBuffer<SIZE>

impl Send for NoA1

impl Send for NoA2

impl Send for NoNI

impl Send for NoS3

impl Send for NoS4

impl Send for YesA1

impl Send for YesA2

impl Send for YesNI

impl Send for YesS3

impl Send for YesS4

impl<NI> Send for Avx2Machine<NI>
where NI: Send,

impl<S3, S4, NI> Send for SseMachine<S3, S4, NI>
where S3: Send, S4: Send, NI: Send,

impl !Send for TokenTree

impl !Send for DelimSpan

impl !Send for Group

impl !Send for Ident

impl !Send for LexError

impl !Send for Literal

impl !Send for Punct

impl !Send for Span

impl !Send for TokenStream

impl !Send for IntoIter

impl Send for Delimiter

impl Send for Spacing

impl !Send for Diagnostic

impl !Send for SpanRange

impl Send for Level

impl Send for DecodeError

impl Send for EncodeError

impl Send for Feature

impl Send for NullValue

impl Send for Syntax

impl Send for Cardinality

impl Send for Kind

impl Send for Label

impl Send for Type

impl Send for CType

impl Send for JsType

impl Send for Kind

impl Send for File

impl Send for Version

impl Send for Annotation

impl Send for Location

impl Send for Any

impl Send for Api

impl Send for Duration

impl Send for Enum

impl Send for EnumOptions

impl Send for EnumValue

impl Send for Field

impl Send for FieldMask

impl Send for FileOptions

impl Send for ListValue

impl Send for Method

impl Send for Mixin

impl Send for Option

impl Send for Struct

impl Send for Timestamp

impl Send for Type

impl Send for Value

impl Send for NamePart

impl Send for Uninhabited

impl Send for RegType

impl Send for TrapKind

impl Send for Val

impl Send for ExtendedOp

impl Send for Op

impl Send for Opcode

impl Send for AnyReg

impl Send for FReg

impl Send for VReg

impl Send for XReg

impl Send for Decoder

impl Send for PcRelOffset

impl Send for U6

impl Send for FRegVal

impl Send for VRegVal

impl Send for Vm

impl Send for XRegVal

impl Send for BrIf

impl Send for BrIfNot

impl Send for BrIfXeq32

impl Send for BrIfXeq32I8

impl Send for BrIfXeq64

impl Send for BrIfXeq64I8

impl Send for BrIfXneq32

impl Send for BrIfXneq64

impl Send for BrIfXslt32

impl Send for BrIfXslt64

impl Send for BrIfXult32

impl Send for BrIfXult64

impl Send for BrTable32

impl Send for Bswap32

impl Send for Bswap64

impl Send for Call

impl Send for Call1

impl Send for Call2

impl Send for Call3

impl Send for Call4

impl Send for F32FromF64

impl Send for F32FromX32S

impl Send for F32FromX32U

impl Send for F32FromX64S

impl Send for F32FromX64U

impl Send for F64FromF32

impl Send for F64FromX32S

impl Send for F64FromX32U

impl Send for F64FromX64S

impl Send for F64FromX64U

impl Send for FConst32

impl Send for FConst64

impl Send for FCopySign32

impl Send for FCopySign64

impl Send for FSelect32

impl Send for FSelect64

impl Send for Fabs32

impl Send for Fabs64

impl Send for Fadd32

impl Send for Fadd64

impl Send for Fceil32

impl Send for Fceil64

impl Send for Fdiv32

impl Send for Fdiv64

impl Send for Feq32

impl Send for Feq64

impl Send for Ffloor32

impl Send for Ffloor64

impl Send for Fload32LeZ

impl Send for Fload64LeZ

impl Send for Flt32

impl Send for Flt64

impl Send for Flteq32

impl Send for Flteq64

impl Send for Fmaximum32

impl Send for Fmaximum64

impl Send for Fminimum32

impl Send for Fminimum64

impl Send for Fmov

impl Send for Fmul32

impl Send for Fmul64

impl Send for Fnearest32

impl Send for Fnearest64

impl Send for Fneg32

impl Send for Fneg64

impl Send for Fneq32

impl Send for Fneq64

impl Send for Fsqrt32

impl Send for Fsqrt64

impl Send for Fstore32LeZ

impl Send for Fstore64LeZ

impl Send for Fsub32

impl Send for Fsub64

impl Send for Ftrunc32

impl Send for Ftrunc64

impl Send for Jump

impl Send for Nop

impl Send for PopFrame

impl Send for PushFrame

impl Send for Ret

impl Send for Sext16

impl Send for Sext32

impl Send for Sext8

impl Send for StackFree32

impl Send for Trap

impl Send for VAddF32x4

impl Send for VAddF64x2

impl Send for VAddI16x8

impl Send for VAddI32x4

impl Send for VAddI64x2

impl Send for VAddI8x16

impl Send for VBand128

impl Send for VBnot128

impl Send for VBor128

impl Send for VBxor128

impl Send for VDivF64x2

impl Send for VFdemote

impl Send for VInsertF32

impl Send for VInsertF64

impl Send for VInsertX16

impl Send for VInsertX32

impl Send for VInsertX64

impl Send for VInsertX8

impl Send for VLoad128G32

impl Send for VLoad128O32

impl Send for VLoad128Z

impl Send for VLoad8x8SZ

impl Send for VLoad8x8UZ

impl Send for VMulF64x2

impl Send for VMulI16x8

impl Send for VMulI32x4

impl Send for VMulI64x2

impl Send for VMulI8x16

impl Send for VPopcnt8x16

impl Send for VShlI16x8

impl Send for VShlI32x4

impl Send for VShlI64x2

impl Send for VShlI8x16

impl Send for VShrI16x8S

impl Send for VShrI16x8U

impl Send for VShrI32x4S

impl Send for VShrI32x4U

impl Send for VShrI64x2S

impl Send for VShrI64x2U

impl Send for VShrI8x16S

impl Send for VShrI8x16U

impl Send for VShuffle

impl Send for VSplatF32

impl Send for VSplatF64

impl Send for VSplatX16

impl Send for VSplatX32

impl Send for VSplatX64

impl Send for VSplatX8

impl Send for VSubF64x2

impl Send for VSubI16x8

impl Send for VSubI32x4

impl Send for VSubI64x2

impl Send for VSubI8x16

impl Send for Vabs16x8

impl Send for Vabs32x4

impl Send for Vabs64x2

impl Send for Vabs8x16

impl Send for Vabsf32x4

impl Send for Vabsf64x2

impl Send for Vceil32x4

impl Send for Vceil64x2

impl Send for Vconst128

impl Send for Vdivf32x4

impl Send for Veq16x8

impl Send for Veq32x4

impl Send for Veq64x2

impl Send for Veq8x16

impl Send for VeqF32x4

impl Send for VeqF64x2

impl Send for Vfloor32x4

impl Send for Vfloor64x2

impl Send for Vfma32x4

impl Send for Vfma64x2

impl Send for VltF32x4

impl Send for VltF64x2

impl Send for VlteqF32x4

impl Send for VlteqF64x2

impl Send for Vmax16x8S

impl Send for Vmax16x8U

impl Send for Vmax32x4S

impl Send for Vmax32x4U

impl Send for Vmax8x16S

impl Send for Vmax8x16U

impl Send for Vmin16x8S

impl Send for Vmin16x8U

impl Send for Vmin32x4S

impl Send for Vmin32x4U

impl Send for Vmin8x16S

impl Send for Vmin8x16U

impl Send for Vmov

impl Send for Vmulf32x4

impl Send for Vneg16x8

impl Send for Vneg32x4

impl Send for Vneg64x2

impl Send for Vneg8x16

impl Send for VnegF64x2

impl Send for Vnegf32x4

impl Send for Vneq16x8

impl Send for Vneq32x4

impl Send for Vneq64x2

impl Send for Vneq8x16

impl Send for VneqF32x4

impl Send for VneqF64x2

impl Send for Vselect

impl Send for Vslt16x8

impl Send for Vslt32x4

impl Send for Vslt64x2

impl Send for Vslt8x16

impl Send for Vslteq16x8

impl Send for Vslteq32x4

impl Send for Vslteq64x2

impl Send for Vslteq8x16

impl Send for Vsqrt32x4

impl Send for Vsqrt64x2

impl Send for Vsubf32x4

impl Send for Vtrunc32x4

impl Send for Vtrunc64x2

impl Send for Vult16x8

impl Send for Vult32x4

impl Send for Vult64x2

impl Send for Vult8x16

impl Send for Vulteq16x8

impl Send for Vulteq32x4

impl Send for Vulteq64x2

impl Send for Vulteq8x16

impl Send for X32FromF32S

impl Send for X32FromF32U

impl Send for X32FromF64S

impl Send for X32FromF64U

impl Send for X64FromF32S

impl Send for X64FromF32U

impl Send for X64FromF64S

impl Send for X64FromF64U

impl Send for XAbs32

impl Send for XAbs64

impl Send for XBand32

impl Send for XBand64

impl Send for XBnot32

impl Send for XBnot64

impl Send for XBor32

impl Send for XBor64

impl Send for XBxor32

impl Send for XBxor64

impl Send for XDiv32S

impl Send for XDiv32U

impl Send for XDiv64S

impl Send for XDiv64U

impl Send for XJump

impl Send for XLoad32LeZ

impl Send for XLoad64LeZ

impl Send for XLoad8S32Z

impl Send for XLoad8U32Z

impl Send for XMul32

impl Send for XMul64

impl Send for XMulHi64S

impl Send for XMulHi64U

impl Send for XRem32S

impl Send for XRem32U

impl Send for XRem64S

impl Send for XRem64U

impl Send for XSelect32

impl Send for XSelect64

impl Send for XStore16LeZ

impl Send for XStore32LeZ

impl Send for XStore64LeZ

impl Send for XStore8G32

impl Send for XStore8O32

impl Send for XStore8Z

impl Send for Xadd128

impl Send for Xadd32

impl Send for Xadd32U32

impl Send for Xadd32U8

impl Send for Xadd64

impl Send for Xadd64U32

impl Send for Xadd64U8

impl Send for Xband32S32

impl Send for Xband32S8

impl Send for Xband64S32

impl Send for Xband64S8

impl Send for Xbmask32

impl Send for Xbmask64

impl Send for Xbor32S32

impl Send for Xbor32S8

impl Send for Xbor64S32

impl Send for Xbor64S8

impl Send for Xbxor32S32

impl Send for Xbxor32S8

impl Send for Xbxor64S32

impl Send for Xbxor64S8

impl Send for Xclz32

impl Send for Xclz64

impl Send for Xconst16

impl Send for Xconst32

impl Send for Xconst64

impl Send for Xconst8

impl Send for Xctz32

impl Send for Xctz64

impl Send for Xeq32

impl Send for Xeq64

impl Send for Xmadd32

impl Send for Xmadd64

impl Send for Xmax32S

impl Send for Xmax32U

impl Send for Xmax64S

impl Send for Xmax64U

impl Send for Xmin32S

impl Send for Xmin32U

impl Send for Xmin64S

impl Send for Xmin64U

impl Send for Xmov

impl Send for XmovFp

impl Send for XmovLr

impl Send for Xmul32S32

impl Send for Xmul32S8

impl Send for Xmul64S32

impl Send for Xmul64S8

impl Send for Xneg32

impl Send for Xneg64

impl Send for Xneq32

impl Send for Xneq64

impl Send for Xone

impl Send for Xpopcnt32

impl Send for Xpopcnt64

impl Send for Xrotl32

impl Send for Xrotl64

impl Send for Xrotr32

impl Send for Xrotr64

impl Send for Xshl32

impl Send for Xshl32U6

impl Send for Xshl64

impl Send for Xshl64U6

impl Send for Xshr32S

impl Send for Xshr32SU6

impl Send for Xshr32U

impl Send for Xshr32UU6

impl Send for Xshr64S

impl Send for Xshr64SU6

impl Send for Xshr64U

impl Send for Xshr64UU6

impl Send for Xslt32

impl Send for Xslt64

impl Send for Xslteq32

impl Send for Xslteq64

impl Send for Xsub128

impl Send for Xsub32

impl Send for Xsub32U32

impl Send for Xsub32U8

impl Send for Xsub64

impl Send for Xsub64U32

impl Send for Xsub64U8

impl Send for Xult32

impl Send for Xult64

impl Send for Xulteq32

impl Send for Xulteq64

impl Send for Xwidemul64S

impl Send for Xwidemul64U

impl Send for Xzero

impl Send for Zext16

impl Send for Zext32

impl Send for Zext8

impl Send for AddrG32

impl Send for AddrG32Bne

impl Send for AddrO32

impl Send for AddrZ

impl<'a> Send for SafeBytecodeStream<'a>

impl<'a> Send for Disassembler<'a>

impl<'a, F, V1, V2> Send for SequencedVisitor<'a, F, V1, V2>
where F: Send, V1: Send, V2: Send,

impl<B> Send for MaterializeOpsVisitor<B>
where B: Send,

impl<D, S1, S2> Send for BinaryOperands<D, S1, S2>
where D: Send, S1: Send, S2: Send,

impl<R> Send for UpperRegSet<R>
where R: Send,

impl<R> Send for UpperRegSetIntoIter<R>
where R: Send,

impl<T> !Send for DoneReason<T>

impl Send for DeError

impl Send for Error

impl Send for EscapeError

impl Send for AttrError

impl Send for QuoteLevel

impl Send for Decoder

impl<'a> Send for DeEvent<'a>

impl<'a> Send for PayloadEvent<'a>

impl<'a> Send for Event<'a>

impl<'a> Send for PrefixDeclaration<'a>

impl<'a> Send for Text<'a>

impl<'a> Send for Attribute<'a>

impl<'a> Send for Attributes<'a>

impl<'a> Send for BytesCData<'a>

impl<'a> Send for BytesDecl<'a>

impl<'a> Send for BytesEnd<'a>

impl<'a> Send for BytesStart<'a>

impl<'a> Send for BytesText<'a>

impl<'a> Send for LocalName<'a>

impl<'a> Send for Namespace<'a>

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

impl<'a> Send for QName<'a>

impl<'a, W> Send for ElementWriter<'a, W>
where W: Send,

impl<'de> Send for SliceReader<'de>

impl<'de, R, E> Send for Deserializer<'de, R, E>
where R: Send, E: Send,

impl<'ns> Send for ResolveResult<'ns>

impl<'w, 'r, W> Send for Serializer<'w, 'r, W>
where W: Send,

impl<R> Send for IoReader<R>
where R: Send,

impl<R> Send for NsReader<R>
where R: Send,

impl<R> Send for Reader<R>
where R: Send,

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

impl<W> Send for Writer<W>
where W: Send,

impl !Send for ThreadRng

impl Send for Error

impl Send for Error

impl Send for IndexVec

impl Send for Empty

impl Send for Alphabetic

impl Send for Bernoulli

impl Send for Open01

impl Send for UniformChar

impl Send for StepRng

impl Send for SmallRng

impl Send for StdRng

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

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

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

impl<D, F, T, S> Send for Map<D, F, T, S>
where D: Send, F: Send,

impl<D, R, T> Send for Iter<D, R, T>
where D: Send, R: Send, T: Send,

impl<R, Rsdr> Send for ReseedingRng<R, Rsdr>
where <R as BlockRngCore>::Results: Send, R: Send, Rsdr: 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 Send for ChaCha12Rng

impl Send for ChaCha20Rng

impl Send for ChaCha8Core

impl Send for ChaCha8Rng

impl Send for OsError

impl Send for OsRng

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

impl<'r, R> Send for UnwrapMut<'r, R>
where R: Send + ?Sized,

impl<R> Send for BlockRng<R>
where <R as BlockRngCore>::Results: Send, R: Send,

impl<R> Send for BlockRng64<R>
where <R as BlockRngCore>::Results: Send, R: Send + ?Sized,

impl<R> Send for UnwrapErr<R>
where R: Send,

impl<'a> Send for Drain<'a>

impl<'a, K, V> Send for Iter<'a, K, V>

impl<'a, K, V> Send for IterMut<'a, K, V>

impl<'a, K, V> Send for Drain<'a, K, V>

impl<'a, K, V> Send for Iter<'a, K, V>

impl<'a, K, V> Send for IterMut<'a, K, V>

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

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

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

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

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

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

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

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

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

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

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

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

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

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

impl<'ch> Send for Bytes<'ch>

impl<'ch> Send for CharIndices<'ch>

impl<'ch> Send for Chars<'ch>

impl<'ch> Send for EncodeUtf16<'ch>

impl<'ch> Send for Lines<'ch>

impl<'ch> Send for SplitAsciiWhitespace<'ch>

impl<'ch> Send for SplitWhitespace<'ch>

impl<'ch, P> Send for MatchIndices<'ch, P>

impl<'ch, P> Send for Matches<'ch, P>

impl<'ch, P> Send for Split<'ch, P>

impl<'ch, P> Send for SplitInclusive<'ch, P>

impl<'ch, P> Send for SplitTerminator<'ch, P>

impl<'data, T> Send for Chunks<'data, T>

impl<'data, T> Send for ChunksExact<'data, T>

impl<'data, T> Send for ChunksExactMut<'data, T>

impl<'data, T> Send for ChunksMut<'data, T>

impl<'data, T> Send for Iter<'data, T>

impl<'data, T> Send for IterMut<'data, T>

impl<'data, T> Send for RChunks<'data, T>

impl<'data, T> Send for RChunksExact<'data, T>

impl<'data, T> Send for RChunksExactMut<'data, T>

impl<'data, T> Send for RChunksMut<'data, T>

impl<'data, T> Send for Windows<'data, T>

impl<'data, T> Send for Drain<'data, T>

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

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

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

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

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

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

impl<A, B> Send for Chain<A, B>

impl<A, B> Send for Zip<A, B>

impl<A, B> Send for ZipEq<A, B>

impl<D, S> Send for Split<D, S>
where D: Send, S: Send,

impl<I> Send for Chunks<I>

impl<I> Send for Cloned<I>

impl<I> Send for Copied<I>

impl<I> Send for Enumerate<I>

impl<I> Send for ExponentialBlocks<I>
where I: Send,

impl<I> Send for Flatten<I>

impl<I> Send for FlattenIter<I>

impl<I> Send for 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 Rev<I>

impl<I> Send for Skip<I>
where I: Send,

impl<I> Send for SkipAny<I>

impl<I> Send for StepBy<I>

impl<I> Send for Take<I>
where I: Send,

impl<I> Send for TakeAny<I>

impl<I> Send for UniformBlocks<I>
where I: Send,

impl<I> Send for WhileSome<I>

impl<I, F> Send for FlatMap<I, F>
where F: Send,

impl<I, F> Send for FlatMapIter<I, F>
where F: Send,

impl<I, F> Send for Inspect<I, F>
where F: Send,

impl<I, F> Send for Map<I, F>
where F: Send,

impl<I, F> Send for Update<I, F>
where F: Send,

impl<I, ID, F> Send for 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 Interleave<I, J>

impl<I, J> Send for InterleaveShortest<I, J>

impl<I, P> Send for Filter<I, P>
where P: Send,

impl<I, P> Send for FilterMap<I, P>
where P: Send,

impl<I, P> Send for 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, 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, ID, F> Send for TryFold<I, U, ID, F>
where I: Send, ID: Send, F: Send, U: Send,

impl<Iter> Send for IterBridge<Iter>
where Iter: Send,

impl<K, V> Send for IntoIter<K, V>

impl<K, V> Send for IntoIter<K, V>

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<T> Send for IntoIter<T>

impl<T> Send for IntoIter<T>

impl<T> Send for IntoIter<T>

impl<T> Send for IntoIter<T>

impl<T> Send for IntoIter<T>

impl<T> Send for Empty<T>

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

impl<T> Send for Once<T>

impl<T> Send for Repeat<T>

impl<T> Send for RepeatN<T>

impl<T> Send for IntoIter<T>

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

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

impl<T> Send for IntoIter<T>

impl<T> Send for IntoIter<T>

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

impl !Send for FnContext

impl Send for Yield

impl Send for ThreadPool

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

impl<'scope> Send for Scope<'scope>

impl<'scope> Send for ScopeFifo<'scope>

impl<S = DefaultSpawn> !Send for ThreadPoolBuilder<S>

impl Send for Direction

impl Send for ErrorKind

impl Send for Expiry

impl Send for PushKind

impl Send for RetryMethod

impl Send for Role

impl Send for SetExpiry

impl Send for TlsMode

impl Send for Value

impl Send for PubSub

impl Send for PubSubSink

impl Send for SendError

impl Send for TcpSettings

impl Send for Client

impl Send for Cmd

impl Send for Connection

impl Send for InfoDict

impl Send for LposOptions

impl Send for Msg

impl Send for Parser

impl Send for Pipeline

impl Send for PushInfo

impl Send for RedisError

impl Send for ReplicaInfo

impl Send for ScanOptions

impl Send for SetOptions

impl<'a> Send for PubSub<'a>

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

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

impl<C> Send for Connection<C>
where C: Send,

impl<C> Send for Monitor<C>
where C: Send,

impl<D> Send for Arg<D>
where D: Send,

impl<U> Send for ControlFlow<U>
where U: Send,

impl !Send for Ctx

impl Send for Algorithm

impl Send for Edit

impl Send for OperandKind

impl Send for OperandPos

impl Send for RegClass

impl Send for IndexSet

impl Send for SetBitsIter

impl Send for Allocation

impl Send for Block

impl Send for Inst

impl Send for InstRange

impl Send for MachineEnv

impl Send for Operand

impl Send for Output

impl Send for PReg

impl Send for PRegSet

impl Send for PRegSetIter

impl Send for ProgPoint

impl Send for SpillSlot

impl Send for VReg

impl<'a> Send for InstOrEdit<'a>

impl<'a> Send for OutputIter<'a>

impl<'a, F> Send for Checker<'a, F>
where F: Sync,

impl Send for Error

impl Send for Regex

impl Send for RegexSet

impl Send for SetMatches

impl Send for Regex

impl Send for RegexSet

impl Send for SetMatches

impl<'a> Send for SetMatchesIter<'a>

impl<'a> Send for SetMatchesIter<'a>

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

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

impl<'c, 'h> Send for SubCaptureMatches<'c, 'h>

impl<'c, 'h> Send for SubCaptureMatches<'c, 'h>

impl<'h> Send for Captures<'h>

impl<'h> Send for Match<'h>

impl<'h> Send for Captures<'h>

impl<'h> Send for Match<'h>

impl<'r> Send for CaptureNames<'r>

impl<'r> Send for CaptureNames<'r>

impl<'r, 'h> Send for CaptureMatches<'r, 'h>

impl<'r, 'h> Send for Matches<'r, 'h>

impl<'r, 'h> Send for Split<'r, 'h>

impl<'r, 'h> Send for SplitN<'r, 'h>

impl<'r, 'h> Send for CaptureMatches<'r, 'h>

impl<'r, 'h> Send for Matches<'r, 'h>

impl<'r, 'h> Send for Split<'r, 'h>

impl<'r, 'h> Send for SplitN<'r, 'h>

impl<'s> Send for NoExpand<'s>

impl<'s> Send for NoExpand<'s>

impl Send for Anchored

impl Send for MatchKind

impl Send for StartError

impl Send for State

impl Send for Look

impl Send for BuildError

impl Send for Builder

impl Send for Cache

impl Send for Config

impl Send for DFA

impl Send for Builder

impl Send for Cache

impl Send for Config

impl Send for DFA

impl Send for Builder

impl Send for Cache

impl Send for Regex

impl Send for BuildError

impl Send for CacheError

impl Send for LazyStateID

impl Send for BuildError

impl Send for Builder

impl Send for Cache

impl Send for Config

impl Send for Regex

impl Send for Builder

impl Send for Cache

impl Send for Config

impl Send for Builder

impl Send for Cache

impl Send for Config

impl Send for PikeVM

impl Send for BuildError

impl Send for Builder

impl Send for Compiler

impl Send for Config

impl Send for NFA

impl Send for Transition

impl Send for HalfMatch

impl Send for Match

impl Send for MatchError

impl Send for PatternID

impl Send for PatternSet

impl Send for Span

impl Send for ByteClasses

impl Send for Unit

impl Send for Captures

impl Send for GroupInfo

impl Send for DebugByte

impl Send for LookMatcher

impl Send for LookSet

impl Send for LookSetIter

impl Send for Prefilter

impl Send for NonMaxUsize

impl Send for SmallIndex

impl Send for StateID

impl Send for Config

impl Send for Config

impl<'a> Send for PatternIter<'a>

impl<'a> Send for PatternSetIter<'a>

impl<'a> Send for ByteClassElements<'a>

impl<'a> Send for ByteClassIter<'a>

impl<'a> Send for CapturesPatternIter<'a>

impl<'a> Send for GroupInfoAllNames<'a>

impl<'a> Send for GroupInfoPatternNames<'a>

impl<'a> Send for DebugHaystack<'a>

impl<'a, T, F> Send for PoolGuard<'a, T, F>
where F: Send + Sync,

impl<'h> Send for Input<'h>

impl<'h> Send for Searcher<'h>

impl<'h, F> Send for CapturesIter<'h, F>
where F: Send,

impl<'h, F> Send for HalfMatchesIter<'h, F>
where F: Send,

impl<'h, F> Send for MatchesIter<'h, F>
where F: Send,

impl<'h, F> Send for TryCapturesIter<'h, F>
where F: Send,

impl<'h, F> Send for TryHalfMatchesIter<'h, F>
where F: Send,

impl<'h, F> Send for TryMatchesIter<'h, F>
where F: Send,

impl<'r, 'c, 'h> Send for FindMatches<'r, 'c, 'h>

impl<'r, 'c, 'h> Send for TryCapturesMatches<'r, 'c, 'h>

impl<'r, 'c, 'h> Send for TryFindMatches<'r, 'c, 'h>

impl<'r, 'c, 'h> Send for CapturesMatches<'r, 'c, 'h>

impl<'r, 'c, 'h> Send for FindMatches<'r, 'c, 'h>

impl<'r, 'h> Send for CapturesMatches<'r, 'h>

impl<'r, 'h> Send for FindMatches<'r, 'h>

impl<'r, 'h> Send for Split<'r, 'h>

impl<'r, 'h> Send for SplitN<'r, 'h>

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

impl<T, F> Send for Lazy<T, F>
where F: Send, T: Send,

impl<T, F> Send for Pool<T, F>
where F: Send, T: Send,

impl Send for Error

impl Send for Regex

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

impl<'c, 'h> Send for SubCaptureMatches<'c, 'h>

impl<'h> Send for Captures<'h>

impl<'h> Send for Match<'h>

impl<'r> Send for CaptureNames<'r>

impl<'r, 'h> Send for CaptureMatches<'r, 'h>

impl<'r, 'h> Send for Matches<'r, 'h>

impl<'r, 'h> Send for Split<'r, 'h>

impl<'r, 'h> Send for SplitN<'r, 'h>

impl<'t> Send for NoExpand<'t>

impl Send for Ast

impl Send for ClassSet

impl Send for ErrorKind

impl Send for Flag

impl Send for GroupKind

impl Send for LiteralKind

impl Send for Error

impl Send for Class

impl Send for Dot

impl Send for ErrorKind

impl Send for HirKind

impl Send for Look

impl Send for ExtractKind

impl Send for Parser

impl Send for Printer

impl Send for Alternation

impl Send for Assertion

impl Send for CaptureName

impl Send for ClassAscii

impl Send for ClassPerl

impl Send for Comment

impl Send for Concat

impl Send for Error

impl Send for Flags

impl Send for FlagsItem

impl Send for Group

impl Send for Literal

impl Send for Position

impl Send for Repetition

impl Send for SetFlags

impl Send for Span

impl Send for Extractor

impl Send for Literal

impl Send for Seq

impl Send for Printer

impl Send for Capture

impl Send for ClassBytes

impl Send for Error

impl Send for Hir

impl Send for Literal

impl Send for LookSet

impl Send for LookSetIter

impl Send for Properties

impl Send for Repetition

impl Send for Translator

impl Send for Parser

impl Send for Utf8Range

impl<'a> Send for ClassBytesIter<'a>

impl<'a> Send for ClassUnicodeIter<'a>

impl Send for Body

impl Send for Client

impl Send for Request

impl Send for Response

impl Send for Name

impl Send for Action

impl Send for Policy

impl Send for Body

impl Send for Client

impl Send for Error

impl Send for NoProxy

impl Send for Proxy

impl Send for Request

impl Send for Response

impl Send for Upgraded

impl Send for Certificate

impl Send for Identity

impl Send for TlsInfo

impl Send for Version

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

impl Send for OpeningKey

impl Send for SealingKey

impl Send for Algorithm

impl Send for Algorithm

impl Send for LessSafeKey

impl Send for Nonce

impl Send for Tag

impl Send for UnboundKey

impl Send for Algorithm

impl Send for PublicKey

impl Send for Algorithm

impl Send for Context

impl Send for Digest

impl Send for KeyRejected

impl Send for Unspecified

impl Send for Algorithm

impl Send for Prk

impl Send for Salt

impl Send for Algorithm

impl Send for Context

impl Send for Key

impl Send for Tag

impl Send for Algorithm

impl Send for Document

impl Send for KeyPair

impl Send for PublicKey

impl Send for Signature

impl<'a> Send for Positive<'a>

impl<'a, L> Send for Okm<'a, L>
where L: Send,

impl<A> Send for Aad<A>
where A: Send,

impl<B> Send for UnparsedPublicKey<B>
where B: Send,

impl<B> Send for PublicKeyComponents<B>
where B: Send,

impl<B> Send for UnparsedPublicKey<B>
where B: Send,

impl<N> Send for OpeningKey<N>
where N: Send,

impl<N> Send for SealingKey<N>
where N: Send,

impl<Public, Private> Send for KeyPairComponents<Public, Private>
where Private: Send, Public: Send,

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

impl Send for Marker

impl Send for ExtMeta

impl Send for ByteBuf

impl<'a> Send for Bytes<'a>

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

impl<E> Send for NumValueReadError<E>
where E: Send,

impl<E> Send for ValueReadError<E>
where E: Send,

impl<E> Send for ValueWriteError<E>
where E: Send,

impl<E> Send for MarkerReadError<E>
where E: Send,

impl Send for BytesMode

impl Send for Error

impl Send for Error

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

impl<'a, W> Send for ExtFieldSerializer<'a, W>
where W: Send,

impl<'a, W> Send for ExtSerializer<'a, W>
where W: Send,

impl<'b, 'c, T> Send for Reference<'b, 'c, T>
where T: Sync + ?Sized,

impl<C> Send for BinaryConfig<C>
where C: Send,

impl<C> Send for HumanReadableConfig<C>
where C: Send,

impl<C> Send for StructMapConfig<C>
where C: Send,

impl<C> Send for StructTupleConfig<C>
where C: Send,

impl<R> Send for ReadReader<R>
where R: Send,

impl<R, C> Send for Deserializer<R, C>
where R: Send, C: Send,

impl<W, C> Send for Serializer<W, C>
where W: Send, C: Send,

impl Send for FxHasher

impl Send for HexU16

impl Send for HexU8

impl<'a> Send for HexSlice<'a>

impl Send for RequestType

impl Send for ClientError

impl Send for Client

impl<'a, E, M> Send for MutatedEndpoint<'a, E, M>

impl<T> Send for EndpointResult<T>

impl !Send for PrctlMmMap

impl Send for Advice

impl Send for FileType

impl Send for SeekFrom

impl Send for Direction

impl Send for Shutdown

impl Send for Timeout

impl Send for EndianMode

impl Send for FlockType

impl Send for PTracer

impl Send for Resource

impl Send for Action

impl Send for ClockId

impl Send for CreateFlags

impl Send for ReadFlags

impl Send for WatchFlags

impl Send for Access

impl Send for AtFlags

impl Send for Dir

impl Send for DirEntry

impl Send for Fsid

impl Send for Gid

impl Send for IFlags

impl Send for MemfdFlags

impl Send for Mode

impl Send for OFlags

impl Send for RenameFlags

impl Send for SealFlags

impl Send for Stat

impl Send for StatFs

impl Send for StatVfs

impl Send for Statx

impl Send for StatxFlags

impl Send for Timespec

impl Send for Timestamps

impl Send for Uid

impl Send for XattrFlags

impl Send for DupFlags

impl Send for Errno

impl Send for FdFlags

impl Send for Protocol

impl Send for RecvFlags

impl Send for RecvMsg

impl Send for ReturnFlags

impl Send for SendFlags

impl Send for SocketFlags

impl Send for SocketType

impl Send for UCred

impl Send for XdpDesc

impl Send for XdpOptions

impl Send for XdpUmemReg

impl Send for DecInt

impl Send for Flock

impl Send for Pid

impl Send for PidfdFlags

impl Send for Rlimit

impl Send for Signal

impl Send for WaitOptions

impl Send for WaitStatus

impl Send for InputModes

impl Send for LocalModes

impl Send for OutputModes

impl Send for Termios

impl Send for Winsize

impl Send for Itimerspec

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

impl<'a> Send for RecvAncillaryMessage<'a>

impl<'a> Send for WaitId<'a>

impl<'a> Send for DynamicClockId<'a>

impl<'a> Send for Event<'a>

impl<'a> Send for RawDirEntry<'a>

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

impl<'a, const OPCODE: u32, Value> Send for Updater<'a, OPCODE, Value>
where Value: Send,

impl<'buf> !Send for AncillaryDrain<'buf>

impl<'buf> Send for RecvAncillaryBuffer<'buf>

impl<'buf, 'slice, 'fd> Send for SendAncillaryBuffer<'buf, 'slice, 'fd>

impl<'buf, Fd> Send for Reader<'buf, Fd>
where Fd: Send,

impl<'buf, Fd> Send for RawDir<'buf, Fd>
where Fd: Send,

impl<'data, T> Send for AncillaryIter<'data, T>
where T: Send,

impl<'slice, 'fd> Send for SendAncillaryMessage<'slice, 'fd>

impl<const OPCODE: u32> !Send for IntegerSetter<OPCODE>

impl<const OPCODE: u32> Send for NoArg<OPCODE>

impl<const OPCODE: u32, Input> Send for Setter<OPCODE, Input>
where Input: Send,

impl<const OPCODE: u32, Output> Send for Getter<OPCODE, Output>
where Output: Send,

impl Send for EchMode

impl Send for EchStatus

impl Send for CipherSuite

impl Send for Connection

impl Send for ContentType

impl Send for Error

impl Send for NamedGroup

impl Send for Side

impl Send for Connection

impl Send for KeyChange

impl Send for Version

impl Send for EncodeError

impl Send for EchConfig

impl Send for Resumption

impl Send for AeadKey

impl Send for Iv

impl Send for Nonce

impl Send for Output

impl Send for Tag

impl Send for HpkeKeyPair

impl Send for HpkeSuite

impl Send for Ticketer

impl Send for OkmBlock

impl Send for Keys

impl Send for Secrets

impl Send for Suite

impl Send for Tag

impl Send for Accepted

impl Send for Acceptor

impl Send for CommonState

impl Send for IoState

impl Send for KeyLogFile

impl Send for NoKeyLog

impl Send for OtherError

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

impl<'a> Send for OutboundChunks<'a>

impl<'a> Send for DangerousClientConfig<'a>

impl<'a> Send for WriteEarlyData<'a>

impl<'a> Send for BorrowedPayload<'a>

impl<'a> Send for InboundOpaqueMessage<'a>

impl<'a> Send for InboundPlainMessage<'a>

impl<'a> Send for OutboundPlainMessage<'a>

impl<'a> Send for PrfUsingHmac<'a>

impl<'a> Send for HkdfUsingHmac<'a>

impl<'a> Send for FfdheGroup<'a>

impl<'a> Send for ClientHello<'a>

impl<'a> Send for ParsedCertificate<'a>

impl<'a> Send for ReadEarlyData<'a>

impl<'a> Send for Reader<'a>

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

impl<'c, 'i, Data> Send for ConnectionState<'c, 'i, Data>
where Data: Send,

impl<'c, 'i, Data> Send for ReadEarlyData<'c, 'i, Data>
where Data: Send,

impl<'c, 'i, Data> Send for ReadTraffic<'c, 'i, Data>
where Data: Send,

impl<'c, 'i, Data> Send for UnbufferedStatus<'c, 'i, Data>
where Data: Send,

impl<'c, Data> Send for EncodeTlsData<'c, Data>
where Data: Send,

impl<'c, Data> Send for TransmitTlsData<'c, Data>
where Data: Send,

impl<'c, Data> Send for WriteTraffic<'c, Data>
where Data: Send,

impl<'i> Send for AppDataRecord<'i>

impl<C, T> Send for StreamOwned<C, T>
where C: Send, T: Send,

impl<Data> Send for ConnectionCommon<Data>
where Data: Send,

impl<Data> Send for ConnectionCommon<Data>
where Data: Send,

impl<Data> Send for UnbufferedConnectionCommon<Data>
where Data: Send,

impl<Side, State> Send for ConfigBuilder<Side, State>
where State: Send, Side: Send,

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

impl Send for ErrorKind

impl Send for Error

impl Send for Error

impl Send for Item

impl Send for IpAddr

impl Send for Error

impl Send for SectionKind

impl Send for Ipv4Addr

impl Send for Ipv6Addr

impl Send for UnixTime

impl<'a> Send for PrivateKeyDer<'a>

impl<'a> Send for ServerName<'a>

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

impl<'a> Send for Der<'a>

impl<'a> Send for DnsName<'a>

impl<'a> Send for EchConfigListBytes<'a>

impl<'a> Send for PrivatePkcs1KeyDer<'a>

impl<'a> Send for PrivatePkcs8KeyDer<'a>

impl<'a> Send for PrivateSec1KeyDer<'a>

impl<'a> Send for SubjectPublicKeyInfoDer<'a>

impl<'a> Send for TrustAnchor<'a>

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

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

impl Send for Buffer

impl<R> Send for SalsaCore<R>
where R: Send,

impl<R> Send for XSalsaCore<R>
where R: Send,

impl Send for Schema

impl Send for Metadata

impl Send for RootSchema

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

impl Send for Always

impl<T, F, S> Send for ScopeGuard<T, F, S>
where T: Send, F: Send,

impl<S> Send for SecretBox<S>
where S: Send + ?Sized,

impl Send for Op

impl Send for Comparator

impl Send for Error

impl Send for Prerelease

impl Send for Version

impl Send for VersionReq

impl Send for IgnoredAny

impl Send for Error

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

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<'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<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<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 I128Deserializer<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 I8Deserializer<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 U128Deserializer<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 U8Deserializer<E>
where E: Send,

impl<E> Send for UnitDeserializer<E>
where E: Send,

impl<E> Send for UsizeDeserializer<E>
where E: Send,

impl<I, E> Send for SeqDeserializer<I, E>
where E: Send, I: Send,

impl<Ok, Error> Send for Impossible<Ok, Error>
where Ok: Send, Error: Send,

impl !Send for Default

impl !Send for Container

impl !Send for Field

impl !Send for Variant

impl Send for Style

impl Send for Identifier

impl Send for RenameRule

impl Send for TagType

impl Send for Derive

impl Send for Name

impl Send for Ctxt

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

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

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

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

impl Send for Value

impl Send for Category

impl Send for CharEscape

impl Send for IntoIter

impl Send for IntoValues

impl Send for Error

impl Send for Number

impl Send for Serializer

impl<'a> Send for Entry<'a>

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

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

impl<'a> Send for Iter<'a>

impl<'a> Send for IterMut<'a>

impl<'a> Send for Keys<'a>

impl<'a> Send for OccupiedEntry<'a>

impl<'a> Send for VacantEntry<'a>

impl<'a> Send for Values<'a>

impl<'a> Send for ValuesMut<'a>

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

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

impl<K, V> Send for Map<K, V>
where K: Send, V: Send,

impl<R> Send for IoRead<R>
where R: Send,

impl<R> Send for Deserializer<R>
where R: Send,

impl<W, F> Send for Serializer<W, F>
where W: Send, F: Send,

impl Send for Error

impl Send for Config

impl<'a, W> Send for QsSerializer<'a, W>
where W: Send,

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

impl Send for Error

impl<'de> Send for Deserializer<'de>

impl<'input, 'output, T> !Send for StructVariantSerializer<'input, 'output, T>

impl<'input, 'output, T> !Send for TupleStructSerializer<'input, 'output, T>

impl<'input, 'output, T> !Send for TupleVariantSerializer<'input, 'output, T>

impl<'input, 'output, Target> !Send for MapSerializer<'input, 'output, Target>

impl<'input, 'output, Target> !Send for SeqSerializer<'input, 'output, Target>

impl<'input, 'output, Target> !Send for StructSerializer<'input, 'output, Target>

impl<'input, 'output, Target> !Send for TupleSerializer<'input, 'output, Target>

impl<'input, 'output, Target> !Send for Serializer<'input, 'output, Target>

impl Send for Value

impl Send for IntoIter

impl Send for IntoKeys

impl Send for IntoValues

impl Send for Error

impl Send for Location

impl Send for Mapping

impl Send for Number

impl Send for Serializer

impl Send for Tag

impl Send for TaggedValue

impl<'a> Send for Entry<'a>

impl<'a> Send for Iter<'a>

impl<'a> Send for IterMut<'a>

impl<'a> Send for Keys<'a>

impl<'a> Send for OccupiedEntry<'a>

impl<'a> Send for VacantEntry<'a>

impl<'a> Send for Values<'a>

impl<'a> Send for ValuesMut<'a>

impl<'de> !Send for Deserializer<'de>

impl<W> !Send for Serializer<W>

impl Send for Sha1Core

impl<'a, T, C = DefaultConfig> !Send for Ref<'a, T, C>

impl<'a, T, C = DefaultConfig> !Send for RefMut<'a, T, C>

impl<'a, T, C = DefaultConfig> !Send for Entry<'a, T, C>

impl<'a, T, C = DefaultConfig> !Send for VacantEntry<'a, T, C>

impl<'a, T, C> !Send for UniqueIter<'a, T, C>

impl Send for SigId

impl Send for Algorithm

impl Send for Error

impl Send for KeyHandle

impl Send for FsKeyStore

impl Send for KeyInfo

impl Send for KeyName

impl Send for KeyRing

impl Send for Error

impl Send for ASN1Block

impl Send for ASN1Class

impl Send for OID

impl Send for SipHasher

impl Send for SipHasher13

impl Send for SipHasher24

impl Send for Hash128

impl Send for SipHasher

impl Send for SipHasher13

impl Send for SipHasher24

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

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

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

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

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

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

impl !Send for Whatever

impl Send for Location

impl Send for NoneError

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

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

impl<E> Send for Report<E>
where E: Send,

impl Send for Domain

impl Send for Protocol

impl Send for RecvFlags

impl Send for SockAddr

impl Send for Socket

impl Send for Type

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

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

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

impl<'s> Send for SockRef<'s>

impl Send for LicenseItem

impl Send for Reason

impl Send for ExprNode

impl Send for Operator

impl Send for ParseError

impl Send for Expression

impl Send for ParseMode

impl Send for ExceptionId

impl Send for LicenseId

impl Send for LicenseReq

impl Send for Licensee

impl<'a> Send for Token<'a>

impl<'a> Send for Lexer<'a>

impl<'a> Send for LexerToken<'a>

impl Send for JwtBundle

impl Send for X509Bundle

impl Send for Certificate

impl Send for PrivateKey

impl Send for SpiffeId

impl Send for TrustDomain

impl Send for Claims

impl Send for JwtSvid

impl Send for X509Svid

impl Send for X509Context

impl Send for X509Source

impl Send for K8s

impl Send for Selector

impl Send for Unix

impl Send for Error

impl<Params> Send for AlgorithmIdentifier<Params>
where Params: Send,

impl<Params, Key> Send for SubjectPublicKeyInfo<Params, Key>
where Key: Send, Params: Send,

impl Send for Error

impl Send for StrSimError

impl Send for ParseError

impl Send for Choice

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

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

impl<F> Send for SyncFuture<F>
where F: Send,

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

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

impl Send for Signal

impl Send for ThreadKind

impl Send for UpdateKind

impl Send for Cpu

impl Send for DiskUsage

impl Send for Gid

impl Send for LoadAvg

impl Send for Pid

impl Send for Process

impl Send for RefreshKind

impl Send for System

impl Send for Uid

impl<'a> Send for ProcessesToUpdate<'a>

impl Send for Advice

impl Send for FdFlags

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

impl Send for CDataModel

impl Send for Endianness

impl Send for Environment

impl Send for ParseError

impl Send for Size

impl Send for Vendor

impl Send for Triple

impl Send for Color

impl Send for ColorChoice

impl Send for Buffer

impl Send for ColorSpec

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

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

impl<W> Send for Ansi<W>
where W: Send,

impl<W> Send for NoColor<W>
where W: Send,

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

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

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

impl<T> Send for CachedIntoIter<T>

impl<T> Send for CachedThreadLocal<T>

impl<T> Send for IntoIter<T>

impl<T> Send for ThreadLocal<T>

impl Send for Month

impl Send for Weekday

impl Send for Error

impl Send for Format

impl Send for Parse

impl Send for Component

impl Send for MonthRepr

impl Send for Padding

impl Send for WeekdayRepr

impl Send for YearRange

impl Send for YearRepr

impl Send for DateKind

impl Send for Day

impl Send for End

impl Send for Hour

impl Send for Ignore

impl Send for Minute

impl Send for Month

impl Send for OffsetHour

impl Send for Ordinal

impl Send for Period

impl Send for Second

impl Send for Subsecond

impl Send for WeekNumber

impl Send for Weekday

impl Send for Year

impl Send for Config

impl Send for Rfc2822

impl Send for Rfc3339

impl Send for Parsed

impl Send for Date

impl Send for Duration

impl Send for Time

impl Send for UtcDateTime

impl Send for UtcOffset

impl<'a> Send for BorrowedFormatItem<'a>

impl<const CONFIG: u128> Send for Iso8601<CONFIG>

impl Send for Day

impl Send for Hour

impl Send for Microsecond

impl Send for Millisecond

impl Send for Minute

impl Send for Nanosecond

impl Send for Second

impl Send for Week

impl<const N: usize> Send for TinyAsciiStr<N>

impl<const N: usize> Send for UnvalidatedTinyAsciiStr<N>

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

impl<'p, 's, T> Send for SliceVecDrain<'p, 's, T>
where T: Send,

impl<'p, A> Send for TinyVecDrain<'p, A>
where <A as Array>::Item: Send,

impl<'p, A, I> Send for ArrayVecSplice<'p, A, I>
where I: Send, A: Send,

impl<'p, A, I> Send for TinyVecSplice<'p, A, I>
where I: Send, A: Send, <A as Array>::Item: Send,

impl<'s, T> Send for SliceVec<'s, T>
where T: Send,

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

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

impl<A> Send for ArrayVec<A>
where A: Send,

impl<A> Send for ArrayVecIterator<A>
where A: Send,

impl !Send for LocalSet

impl Send for RecvError

impl Send for DirBuilder

impl Send for DirEntry

impl Send for File

impl Send for OpenOptions

impl Send for ReadDir

impl Send for Empty

impl Send for Interest

impl Send for Ready

impl Send for Repeat

impl Send for Sink

impl Send for Stderr

impl Send for Stdin

impl Send for Stdout

impl Send for TryIoError

impl Send for TcpListener

impl Send for TcpSocket

impl Send for TcpStream

impl Send for UdpSocket

impl Send for UnixSocket

impl Send for UnixStream

impl Send for OpenOptions

impl Send for Receiver

impl Send for Sender

impl Send for SocketAddr

impl Send for UCred

impl Send for Child

impl Send for ChildStderr

impl Send for ChildStdin

impl Send for ChildStdout

impl Send for Command

impl Send for Builder

impl Send for Handle

impl Send for Runtime

impl Send for Signal

impl Send for SignalKind

impl Send for RecvError

impl Send for Barrier

impl Send for Notify

impl Send for Semaphore

impl Send for RecvError

impl Send for Id

impl Send for JoinError

impl Send for Elapsed

impl Send for Error

impl Send for Instant

impl Send for Interval

impl Send for Sleep

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

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

impl<'a> Send for ReadHalf<'a>

impl<'a> Send for WriteHalf<'a>

impl<'a> Send for ReadHalf<'a>

impl<'a> Send for WriteHalf<'a>

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

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

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 MutexGuard<'a, T>
where T: Send + ?Sized,

impl<F> Send for Unconstrained<F>
where F: Send,

impl<R> Send for BufReader<R>
where R: Send,

impl<R> Send for Lines<R>
where R: Send,

impl<R> Send for Split<R>
where R: Send,

impl<R> Send for Take<R>
where R: Send,

impl<R, W> Send for Join<R, W>
where R: Send, W: Send,

impl<RW> Send for BufStream<RW>
where RW: Send,

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

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

impl<T> Send for TrySendError<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 SendError<T>
where T: Send,

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

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

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

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

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

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

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

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

impl<T> Send for 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 Receiver<T>
where T: Send,

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

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

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

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

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

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

impl<T> Send for LocalKey<T>

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

impl<T, F> Send for TaskLocalFuture<T, F>
where T: Send, F: Send,

impl<W> Send for BufWriter<W>
where W: Send,

impl Send for Host

impl Send for SslMode

impl Send for Severity

impl Send for NoTlsStream

impl Send for Config

impl Send for DbError

impl Send for Error

impl Send for SqlState

impl Send for Row

impl Send for CancelToken

impl Send for Client

impl Send for Column

impl Send for Portal

impl Send for RowStream

impl Send for Socket

impl Send for Statement

impl Send for NoTls

impl Send for NoTlsError

impl Send for NoTlsFuture

impl<'a> Send for Transaction<'a>

impl<'a> Send for TransactionBuilder<'a>

impl<S, T> Send for Connection<S, T>
where S: Send, T: Send,

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

impl Send for TlsAcceptor

impl<IO> Send for TlsStream<IO>
where IO: Send,

impl<IO> Send for TlsStream<IO>
where IO: Send,

impl<IO> Send for Accept<IO>
where IO: Send,

impl<IO> Send for Connect<IO>
where IO: Send,

impl<IO> Send for FallibleAccept<IO>
where IO: Send,

impl<IO> Send for FallibleConnect<IO>
where IO: Send,

impl<IO> Send for LazyConfigAcceptor<IO>
where IO: Send,

impl<IO> Send for StartHandshake<IO>
where IO: Send,

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

impl Send for Elapsed

impl<I> Send for Iter<I>
where I: Send,

impl<K, V> Send for StreamMap<K, V>
where K: Send, V: Send,

impl<S> Send for ChunksTimeout<S>
where S: Send, <S as Stream>::Item: Send,

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

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

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

impl<St> Send for Skip<St>
where St: Send,

impl<St> Send for Take<St>
where St: Send,

impl<St, F> Send for Filter<St, F>
where St: Send, F: Send,

impl<St, F> Send for FilterMap<St, F>
where St: Send, F: Send,

impl<St, F> Send for Map<St, F>
where St: Send, F: Send,

impl<St, F> Send for MapWhile<St, F>
where St: Send, F: Send,

impl<St, F> Send for SkipWhile<St, F>
where St: Send, F: Send,

impl<St, F> Send for TakeWhile<St, F>
where St: Send, F: Send,

impl<St, Fut, F> Send for Then<St, Fut, F>
where St: Send, F: Send, Fut: Send,

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

impl<T> Send for Peekable<T>
where <T as Stream>::Item: Send, T: Send,

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

impl<T> Send for BroadcastStream<T>

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

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

impl<T> Send for WatchStream<T>

impl<T, U> Send for Chain<T, U>
where U: Send, T: Send,

impl<T, U> Send for Merge<T, U>
where T: Send, U: Send,

impl Send for EntryType

impl Send for HeaderMode

impl Send for Unpacked

impl Send for GnuHeader

impl Send for Header

impl Send for OldHeader

impl Send for UstarHeader

impl<'entry> Send for PaxExtension<'entry>

impl<'entry> Send for PaxExtensions<'entry>

impl<R> Send for Archive<R>
where R: Send,

impl<R> Send for ArchiveBuilder<R>
where R: Send,

impl<R> Send for Entries<R>
where R: Send,

impl<R> Send for Entry<R>
where R: Send,

impl<W> Send for Builder<W>

impl Send for Builder

impl Send for BytesCodec

impl Send for LinesCodec

impl Send for DropGuard

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

impl<L, R> Send for Either<L, R>
where L: Send, R: Send,

impl<R> Send for ReaderStream<R>
where R: Send,

impl<R, F> Send for InspectReader<R, F>
where R: Send, F: Send,

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

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

impl<S, B> Send for StreamReader<S, B>
where S: Send, B: Send,

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

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

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

impl<T, D> Send for FramedRead<T, D>
where T: Send, D: Send,

impl<T, E> Send for FramedWrite<T, E>
where T: Send, E: Send,

impl<T, U> Send for Framed<T, U>
where T: Send, U: Send,

impl<T, U> Send for FramedParts<T, U>
where T: Send, U: Send,

impl<W, F> Send for InspectWriter<W, F>
where W: Send, F: Send,

impl Send for Value

impl Send for Error

impl Send for IntoIter

impl Send for Error

impl<'a> Send for Entry<'a>

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

impl<'a> Send for Iter<'a>

impl<'a> Send for IterMut<'a>

impl<'a> Send for Keys<'a>

impl<'a> Send for OccupiedEntry<'a>

impl<'a> Send for VacantEntry<'a>

impl<'a> Send for Values<'a>

impl<'a> Send for Deserializer<'a>

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

impl<'d> Send for Serializer<'d>

impl<K, V> Send for Map<K, V>
where K: Send, V: Send,

impl Send for Offset

impl Send for Date

impl Send for Datetime

impl Send for Time

impl Send for Item

impl Send for Value

impl Send for Error

impl Send for Error

impl Send for Array

impl Send for Decor

impl Send for DocumentMut

impl Send for InlineTable

impl Send for Key

impl Send for RawString

impl Send for Repr

impl Send for Table

impl Send for TomlError

impl<'a> Send for Entry<'a>

impl<'a> Send for InlineEntry<'a>

impl<'a> Send for InlineOccupiedEntry<'a>

impl<'a> Send for InlineVacantEntry<'a>

impl<'a> Send for OccupiedEntry<'a>

impl<'a> Send for VacantEntry<'a>

impl<'k> Send for KeyMut<'k>

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

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

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

impl<'s> Send for TomlKey<'s>

impl<'s> Send for TomlKeyBuilder<'s>

impl<'s> Send for TomlString<'s>

impl<'s> Send for TomlStringBuilder<'s>

impl Send for Code

impl Send for Ascii

impl Send for Binary

impl Send for ToStrError

impl Send for MetadataMap

impl Send for Routes

impl Send for Status

impl Send for TcpIncoming

impl Send for Channel

impl Send for Endpoint

impl Send for Error

impl<'a> Send for KeyAndMutValueRef<'a>

impl<'a> Send for KeyAndValueRef<'a>

impl<'a> Send for KeyRef<'a>

impl<'a> Send for ValueRef<'a>

impl<'a> Send for ValueRefMut<'a>

impl<'a> Send for DecodeBuf<'a>

impl<'a> Send for EncodeBuf<'a>

impl<'a> Send for Iter<'a>

impl<'a> Send for IterMut<'a>

impl<'a> Send for Keys<'a>

impl<'a> Send for Values<'a>

impl<'a> Send for ValuesMut<'a>

impl<'a> Send for GrpcMethod<'a>

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

impl<'a, VE> Send for GetAll<'a, VE>
where VE: Send,

impl<'a, VE> Send for OccupiedEntry<'a, VE>
where VE: Send,

impl<'a, VE> Send for VacantEntry<'a, VE>
where VE: Send,

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

impl<'a, VE> Send for ValueIter<'a, VE>
where VE: Send,

impl<F> Send for InterceptorLayer<F>
where F: Send,

impl<F> Send for ResponseFuture<F>
where F: Send,

impl<L> Send for Router<L>
where L: Send,

impl<L> Send for Server<L>
where L: Send,

impl<S, F> Send for InterceptedService<S, F>
where S: Send, F: Send,

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

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

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

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

impl<T> Send for Streaming<T>

impl<T, U> Send for EncodeBody<T, U>
where T: Send, U: Send,

impl<T, U> Send for ProstCodec<T, U>
where T: Send, U: Send,

impl<VE> Send for MetadataKey<VE>
where VE: Send,

impl<VE> Send for MetadataValue<VE>
where VE: Send,

impl Send for Elapsed

impl Send for None

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

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

impl<A, B> Send for Either<A, B>
where A: Send, B: Send,

impl<A, B> Send for EitherResponseFuture<A, B>
where A: Send, B: 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 MapRequestLayer<F>
where F: Send,

impl<F> Send for 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, 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, S> Send for FutureService<F, S>
where F: Send, S: 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<H> Send for HasherRng<H>
where H: 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<L> Send for ServiceBuilder<L>
where L: Send,

impl<M, Request> Send for IntoService<M, Request>
where M: Send, Request: Send,

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

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

impl<S, F> Send for AndThen<S, F>
where S: Send, F: Send,

impl<S, F> Send for 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 MapRequest<S, F>
where S: Send, F: Send,

impl<S, F> Send for 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 Then<S, F>
where S: Send, F: Send,

impl<S, Req> Send for Oneshot<S, Req>
where S: Send, <S as Service<Req>>::Future: Send, Req: 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 ResponseFuture<T>
where T: Send,

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

impl<T> Send for 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, Request> Send for ReadyOneshot<T, Request>
where T: 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 Send for GrpcCode

impl Send for LatencyUnit

impl Send for AllowOrigin

impl Send for Any

impl Send for CorsLayer

impl Send for MaxAge

impl Send for Vary

impl<C> Send for SharedClassifier<C>
where C: Send,

impl<C, F> Send for MapFailureClass<C, F>
where C: Send, F: Send,

impl<F> Send for ResponseFuture<F>
where F: Send,

impl<FailureClass, ClassifyEos> Send for ClassifiedResponse<FailureClass, ClassifyEos>
where ClassifyEos: Send, FailureClass: Send,

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

impl<T> Send for NeverClassifyEos<T>

impl Send for Identity

impl<F> Send for LayerFn<F>
where F: Send,

impl<Inner, Outer> Send for Stack<Inner, Outer>
where Inner: Send, Outer: Send,

impl !Send for EnteredSpan

impl Send for Span

impl<'a> Send for Entered<'a>

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

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

impl Send for NonBlocking

impl Send for WorkerGuard

impl Send for Builder

impl Send for InitError

impl Send for Rotation

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

impl Send for Identifier

impl Send for Empty

impl Send for FieldSet

impl Send for Iter

impl Send for Kind

impl Send for Current

impl Send for Id

impl Send for Dispatch

impl Send for Field

impl Send for Level

impl Send for LevelFilter

impl Send for Interest

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

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

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

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

impl<'a> Send for Metadata<'a>

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

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

impl Send for Error

impl<S, W> Send for FlameLayer<S, W>
where S: Send, W: Send,

impl<W> Send for FlushGuard<W>
where W: Send,

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

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

impl Send for OtelData

impl<S, T> Send for OpenTelemetryLayer<S, T>
where T: Send, S: Send,

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

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

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

impl<'a> Send for SerializeField<'a>

impl<'a> Send for SerializeFieldSet<'a>

impl<'a> Send for SerializeId<'a>

impl<'a> Send for SerializeLevel<'a>

impl<'a> Send for SerializeMetadata<'a>

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

impl<S> Send for SerdeMapVisitor<S>
where S: Send, <S as SerializeMap>::Error: Send,

impl<S> Send for SerdeStructVisitor<S>
where S: Send, <S as SerializeStruct>::Error: Send,

impl Send for BadName

impl Send for Builder

impl Send for Directive

impl Send for EnvFilter

impl Send for FilterId

impl Send for ParseError

impl Send for IntoIter

impl Send for Targets

impl Send for Compact

impl Send for FmtSpan

impl Send for Full

impl Send for Json

impl Send for JsonFields

impl Send for Pretty

impl Send for TestWriter

impl Send for SystemTime

impl Send for Uptime

impl Send for Identity

impl Send for Registry

impl Send for Error

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

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

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

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

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

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

impl<'a> Send for Iter<'a>

impl<'a, F> !Send for FieldFnVisitor<'a, F>

impl<'a, R> Send for Scope<'a, R>
where R: Sync,

impl<'a, R> Send for ScopeFromRoot<'a, R>
where <R as LookupSpan<'a>>::Data: Send, R: Sync,

impl<'a, R> Send for SpanRef<'a, R>
where <R as LookupSpan<'a>>::Data: Send, R: Sync,

impl<'a, S> Send for Context<'a, S>
where S: Sync,

impl<'a, S, N> !Send for FmtContext<'a, S, N>

impl<'a, W> !Send for MutexGuardWriter<'a, W>

impl<'writer> !Send for Writer<'writer>

impl<A, B> Send for EitherWriter<A, B>
where A: Send, B: Send,

impl<A, B> Send for OrElse<A, B>
where A: Send, B: Send,

impl<A, B> Send for Tee<A, B>
where A: Send, B: Send,

impl<A, B, S> Send for And<A, B, S>
where A: Send, B: Send,

impl<A, B, S> Send for Or<A, B, S>
where A: Send, B: Send,

impl<A, S> Send for Not<A, S>
where A: Send,

impl<D, V> Send for Delimited<D, V>
where D: Send, V: Send,

impl<D, V> Send for VisitDelimited<D, V>
where D: Send, V: Send,

impl<E> Send for FormattedFields<E>
where E: ?Sized,

impl<F> Send for FilterFn<F>
where F: Send,

impl<F> Send for FieldFn<F>
where F: Send,

impl<F, T> Send for Format<F, T>
where F: Send, T: Send,

impl<L, F, S> Send for Filtered<L, F, S>
where F: Send, L: Send,

impl<L, I, S> Send for Layered<L, I, S>
where L: Send, I: Send,

impl<L, S> Send for Handle<L, S>
where L: Send + Sync,

impl<L, S> Send for Layer<L, S>
where L: Send + Sync,

impl<M> Send for WithMaxLevel<M>
where M: Send,

impl<M> Send for WithMinLevel<M>
where M: Send,

impl<M, F> Send for WithFilter<M, F>
where M: Send, F: Send,

impl<N, E, F, W> Send for Subscriber<N, E, F, W>
where F: Send, W: Send, N: Send, E: Send,

impl<N, E, F, W> Send for SubscriberBuilder<N, E, F, W>
where F: Send, W: Send, N: Send, E: Send,

impl<S, F, R> Send for DynFilterFn<S, F, R>
where F: Send, R: Send,

impl<S, N, E, W> Send for Layer<S, N, E, W>
where W: Send, N: Send, E: Send,

impl<V> Send for Alt<V>
where V: Send,

impl<V> Send for Messages<V>
where V: Send,

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

impl Send for RetryPolicy

impl Send for NoBackoff

impl Send for NoOnRetry

impl<BackoffT, OnRetryT> Send for RetryFutureConfig<BackoffT, OnRetryT>
where BackoffT: Send, OnRetryT: Send,

impl<F> Send for RetryFn<F>
where F: Send,

impl<MakeFutureT, FutureT, BackoffT, OnRetryT> Send for RetryFuture<MakeFutureT, FutureT, BackoffT, OnRetryT>
where MakeFutureT: Send, FutureT: Send, BackoffT: Send, OnRetryT: Send,

impl Send for XxHash32

impl Send for XxHash64

impl Send for Hash128

impl Send for Hash64

impl Send for ATerm

impl Send for B0

impl Send for B1

impl Send for Z0

impl Send for Equal

impl Send for Greater

impl Send for Less

impl Send for UTerm

impl<U> Send for NInt<U>
where U: Send,

impl<U> Send for PInt<U>
where U: Send,

impl<U, B> Send for UInt<U, B>
where U: Send, B: Send,

impl<V, A> Send for TArr<V, A>
where V: Send, A: Send,

impl Send for DecodeError

impl Send for EncodeError

impl Send for Generator

impl Send for Ulid

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

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

impl Send for BidiClass

impl Send for Direction

impl Send for Error

impl Send for Level

impl<'a, 'text> Send for Paragraph<'a, 'text>

impl<'a, 'text> Send for Paragraph<'a, 'text>

impl<'text> Send for BidiInfo<'text>

impl<'text> Send for InitialInfo<'text>

impl<'text> Send for ParagraphBidiInfo<'text>

impl<'text> Send for Utf8IndexLenIter<'text>

impl<'text> Send for BidiInfo<'text>

impl<'text> Send for InitialInfo<'text>

impl<'text> Send for ParagraphBidiInfo<'text>

impl<'text> Send for Utf16CharIndexIter<'text>

impl<'text> Send for Utf16CharIter<'text>

impl<'text> Send for Utf16IndexLenIter<'text>

impl<I> Send for Decompositions<I>
where I: Send,

impl<I> Send for Recompositions<I>
where I: Send,

impl<I> Send for Replacements<I>
where I: Send,

impl<I> Send for StreamSafe<I>
where I: Send,

impl Send for EmojiStatus

impl Send for Error

impl !Send for yaml_event_t

impl !Send for yaml_node_t

impl !Send for yaml_token_t

impl Send for yaml_mark_t

impl<T> !Send for yaml_stack_t<T>

impl Send for EndOfInput

impl<'a> Send for Input<'a>

impl<'a> Send for Reader<'a>

impl Send for Origin

impl Send for ParseError

impl Send for Position

impl Send for Url

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

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

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

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

impl<Str> Send for Encoded<Str>
where Str: Send,

impl<'a> Send for Utf16CharIndices<'a>

impl<'a> Send for Utf16Chars<'a>

impl<'a> Send for ErrorReportingUtf8Chars<'a>

impl<'a> Send for Utf8CharIndices<'a>

impl<'a> Send for Utf8Chars<'a>

impl Send for Utf8Codec

impl Send for Parser

impl Send for Number

impl Send for Deprecated

impl Send for Required

impl Send for HttpMethod

impl Send for ParameterIn

impl Send for ArrayItems

impl Send for KnownFormat

impl Send for Schema

impl Send for SchemaType

impl Send for Type

impl Send for ApiKey

impl Send for Flow

impl Send for Content

impl Send for Encoding

impl Send for Example

impl Send for Extensions

impl Send for Header

impl Send for Contact

impl Send for Info

impl Send for InfoBuilder

impl Send for License

impl Send for Link

impl Send for LinkBuilder

impl Send for Operation

impl Send for Parameter

impl Send for PathItem

impl Send for Paths

impl Send for RequestBody

impl Send for Response

impl Send for Responses

impl Send for AllOf

impl Send for AnyOf

impl Send for Array

impl Send for Components

impl Send for Object

impl Send for OneOf

impl Send for Ref

impl Send for RefBuilder

impl Send for ApiKeyValue

impl Send for Http

impl Send for HttpBuilder

impl Send for Implicit

impl Send for OAuth2

impl Send for Password

impl Send for Scopes

impl Send for Server

impl Send for OpenApi

impl Send for Tag

impl Send for TagBuilder

impl Send for Xml

impl Send for XmlBuilder

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

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

impl Send for Variant

impl Send for Version

impl Send for Braced

impl Send for Hyphenated

impl Send for Simple

impl Send for Urn

impl Send for Builder

impl Send for Error

impl Send for NonNilUuid

impl Send for Uuid

impl Send for ContextV7

impl Send for NoContext

impl Send for Timestamp

impl<C> Send for ThreadLocalContext<C>

impl Send for KeyType

impl Send for DataKeyType

impl Send for ReadKeyData

impl Send for ClientError

impl Send for TidyRequest

impl Send for Alias

impl Send for KeyInfo

impl Send for TidyRequest

impl Send for KeyInfo

impl Send for AuthInfo

impl Send for WrapInfo

impl Send for SealRequest

impl Send for TidyRequest

impl Send for VaultClient

impl<E> Send for WrappedResponse<E>

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

impl Send for AsciiCase

impl Send for PodTypeId

impl Send for AVX2

impl Send for Fallback

impl Send for NEON

impl Send for SSE2

impl Send for SSE41

impl Send for SSSE3

impl Send for WASM128

impl Send for Native

impl Send for V128

impl Send for V256

impl Send for V512

impl Send for V64

impl<V> Send for AlswLut<V>
where V: Send,

impl Send for ClientError

impl Send for Client

impl Send for GetResult

impl Send for PutResult

impl Send for StatusType

impl Send for GetResult

impl Send for Properties

impl Send for PutResult

impl Send for StatusType

impl Send for Properties

impl Send for Status

impl Send for StatusInfo

impl Send for TraitStatus

impl Send for VersionInfo

impl Send for Component

impl Send for Metadata

impl Send for OamManifest

impl Send for Policy

impl Send for Spread

impl Send for Status

impl Send for StatusInfo

impl Send for Trait

impl Send for TraitStatus

impl Send for VersionInfo

impl Send for Component

impl Send for Manifest

impl Send for Metadata

impl Send for Policy

impl Send for Spread

impl Send for Trait

impl Send for Closed

impl Send for Giver

impl Send for SharedGiver

impl Send for Taker

impl Send for Account

impl Send for Cluster

impl Send for Component

impl Send for Host

impl Send for Invocation

impl Send for Operator

impl Send for Error

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

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

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

impl Send for BlockType

impl Send for Catch

impl Send for EntityType

impl Send for ExportKind

impl Send for Handle

impl Send for HeapType

impl Send for ModuleArg

impl Send for Ordering

impl Send for SectionId

impl Send for StorageType

impl Send for TagKind

impl Send for TypeBounds

impl Send for ValType

impl Send for ArrayType

impl Send for BranchHint

impl Send for BranchHints

impl Send for CodeSection

impl Send for Component

impl Send for ConstExpr

impl Send for ContType

impl Send for DataSection

impl Send for FieldType

impl Send for FuncType

impl Send for Function

impl Send for GlobalType

impl Send for MemArg

impl Send for MemoryType

impl Send for Module

impl Send for ModuleType

impl Send for NameMap

impl Send for NameSection

impl Send for RefType

impl Send for StructType

impl Send for SubType

impl Send for SymbolTable

impl Send for TableType

impl Send for TagSection

impl Send for TagType

impl Send for TypeSection

impl<'a> Send for Alias<'a>

impl<'a> Send for DataSegmentMode<'a>

impl<'a> Send for ElementMode<'a>

impl<'a> Send for Elements<'a>

impl<'a> Send for Instruction<'a>

impl<'a> Send for ComponentTypeEncoder<'a>

impl<'a> Send for CoreTypeEncoder<'a>

impl<'a> Send for CustomSection<'a>

impl<'a> Send for ElementSegment<'a>

impl<'a> Send for InstructionSink<'a>

impl<'a> Send for ModuleSection<'a>

impl<'a> Send for NestedComponentSection<'a>

impl<'a> Send for RawCustomSection<'a>

impl<'a> Send for RawSection<'a>

impl<'a, D> Send for DataSegment<'a, D>
where D: Send,

impl<A> Send for ComponentStartSection<A>
where A: Send,

impl Send for ExportType

impl Send for Imm

impl Send for ImportType

impl Send for Element

impl Send for Func

impl Send for FuncCode

impl Send for FuncExport

impl Send for FuncType

impl Send for Table

impl Send for WasmCodeGen

impl Send for Payload

impl Send for AddMetadata

impl Send for Author

impl Send for Description

impl Send for Homepage

impl Send for Licenses

impl Send for Metadata

impl Send for Producers

impl Send for Revision

impl Send for Source

impl Send for Version

impl<'a> Send for ComponentNames<'a>

impl<'a> Send for ModuleNames<'a>

impl<'a> Send for ProducersField<'a>

impl Send for BoolCodec

impl Send for F32Codec

impl Send for F64Codec

impl Send for FlagEncoder

impl Send for S16Codec

impl Send for S32Codec

impl Send for S64Codec

impl Send for S8Codec

impl Send for U16Codec

impl Send for U32Codec

impl Send for U64Codec

impl Send for U8Codec

impl<C, V> Send for TupleDecoder<C, V>
where C: Send, V: Send,

impl<E> Send for CoreVecEncoder<E>
where E: Send,

impl<O, E> Send for ResultDecoder<O, E>
where O: Send, E: Send,

impl<O, E> Send for ResultEncoder<O, E>
where O: Send, E: Send,

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

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

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

impl<T> Send for CoreVecDecoder<T>
where T: Send, <T as Decoder>::Item: Send,

impl<const N: usize> Send for FlagDecoder<N>

impl Send for Args

impl Send for Client

impl Send for Host

impl Send for HostBuilder

impl Send for HostLabel

impl Send for Link

impl Send for LinkBuilder

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

impl Send for HttpMethod

impl Send for Level

impl Send for CacheResult

impl Send for SecretValue

impl Send for HostData

impl Send for Cors

impl Send for CorsOrigin

impl Send for Tls

impl Send for OciFetcher

impl Send for OtelConfig

impl Send for RequestBody

impl Send for RequestKind

impl Send for Config

impl Send for HostInfo

impl Send for Manager

impl Send for Response

impl Send for Manager

impl Send for HostMetrics

impl Send for Host

impl Send for Features

impl Send for Host

impl Send for FsProvider

impl Send for Client

impl Send for WrpcClient

impl Send for Context

impl<'a> Send for LinkConfig<'a>

impl Send for ConfigError

impl Send for Error

impl Send for Error

impl Send for Error

impl Send for Level

impl Send for Error

impl Send for SecretValue

impl Send for Level

impl Send for StreamError

impl Send for Error

impl Send for Error

impl Send for ObjectId

impl Send for KeyResponse

impl Send for Interfaces

impl Send for Error

impl Send for Pollable

impl Send for InputStream

impl Send for KeyResponse

impl Send for Features

impl Send for Runtime

impl<C> Send for WrpcServeEvent<C>
where C: Send,

impl<H> Send for Component<H>

impl<H, C> Send for Instance<H, C>
where C: Send,

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

impl Send for Client

impl Send for Application

impl Send for Context

impl Send for Policy

impl Send for Secret

impl Send for FlushGuard

impl<'a> Send for TraceContextExtractor<'a>

impl<'a> Send for HeaderExtractor<'a>

impl<'a> Send for HeaderInjector<'a>

impl Send for Config

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

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

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

impl Send for Type

impl Send for Val

impl Send for CallHook

impl Send for CodeHint

impl Send for Collector

impl Send for Extern

impl Send for ExternType

impl Send for Finality

impl Send for HeapType

impl Send for MpkEnabled

impl Send for Mutability

impl Send for OptLevel

impl Send for Precompiled

impl Send for Ref

impl Send for StorageType

impl Send for Strategy

impl Send for Val

impl Send for ValType

impl Send for WaitResult

impl Send for Component

impl Send for Func

impl Send for Instance

impl Send for ResourceAny

impl Send for WasmStr

impl Send for Component

impl Send for Enum

impl Send for Flags

impl Send for List

impl Send for Module

impl Send for OptionType

impl Send for Record

impl Send for ResultType

impl Send for Tuple

impl Send for Variant

impl Send for AnyRef

impl Send for ArrayRef

impl Send for ArrayRefPre

impl Send for ArrayType

impl Send for CodeMemory

impl Send for Config

impl Send for Engine

impl Send for EngineWeak

impl Send for EqRef

impl Send for ExternRef

impl Send for FieldType

impl Send for FrameInfo

impl Send for FrameSymbol

impl Send for Func

impl Send for FuncType

impl Send for Global

impl Send for GlobalType

impl Send for I31

impl Send for Instance

impl Send for Memory

impl Send for MemoryType

impl Send for Module

impl Send for NoExtern

impl Send for NoFunc

impl Send for NoneRef

impl Send for RefType

impl Send for StoreLimits

impl Send for StructRef

impl Send for StructType

impl Send for Table

impl Send for TableType

impl Send for Tag

impl Send for TagType

impl Send for V128

impl<'a> Send for Case<'a>

impl<'a> Send for Field<'a>

impl<'a> Send for CodeBuilder<'a>

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

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

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

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

impl<'instance> Send for Export<'instance>

impl<'module> Send for ExportType<'module>

impl<'module> Send for ImportType<'module>

impl<C> Send for RootScope<C>
where C: Send,

impl<Params, Results> Send for TypedFunc<Params, Results>

impl<Params, Return> Send for TypedFunc<Params, Return>
where Params: Send, Return: Send,

impl<T> Send for InstancePre<T>

impl<T> Send for Linker<T>

impl<T> Send for Resource<T>

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

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

impl<T> Send for InstancePre<T>

impl<T> Send for Linker<T>

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

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

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

impl Send for CacheConfig

impl<'config> Send for ModuleCacheEntry<'config>

impl Send for FlagsSize

impl Send for Relocation

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

impl<T> Send for IsaBuilder<T>

impl Send for FiberStack

impl<'a, Resume, Yield, Return> Send for Fiber<'a, Resume, Yield, Return>
where Resume: Sync, Yield: Sync, Return: Sync,

impl<Resume, Yield, Return> !Send for Suspend<Resume, Yield, Return>

impl Send for Id

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

impl Send for Advice

impl Send for Descriptor

impl Send for ErrorCode

impl Send for ErrorCode

impl Send for IpAddress

impl Send for Advice

impl Send for ErrorCode

impl Send for StreamError

impl Send for IsATTY

impl Send for LinkOptions

impl Send for LinkOptions

impl Send for Datetime

impl Send for Guest

impl Send for OpenFlags

impl Send for PathFlags

impl Send for LinkOptions

impl Send for TcpSocket

impl Send for UdpSocket

impl Send for Command

impl Send for LinkOptions

impl Send for Guest

impl Send for OpenFlags

impl Send for PathFlags

impl Send for Command

impl Send for LinkOptions

impl Send for DirPerms

impl Send for FilePerms

impl Send for I32Exit

impl Send for Network

impl Send for OutputFile

impl Send for Stderr

impl Send for Stdin

impl Send for Stdout

impl Send for WasiCtx

impl<T> Send for CommandPre<T>

impl<T> Send for CommandPre<T>

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

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

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

impl Send for ErrorCode

impl Send for HeaderError

impl Send for Method

impl Send for Scheme

impl Send for HostFields

impl Send for Datetime

impl Send for Guest

impl Send for Proxy

impl Send for Datetime

impl Send for Guest

impl Send for Proxy

impl Send for HttpError

impl Send for WasiHttpCtx

impl<T> Send for ProxyPre<T>

impl<T> Send for ProxyPre<T>

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

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

impl Send for StreamError

impl Send for StreamError

impl Send for Bindings

impl Send for DynPollable

impl<T> Send for BindingsPre<T>

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

impl Send for AsyncConfig

impl Send for CallStyle

impl Send for Ownership

impl Send for Opts

impl Send for DerTypeId

impl Send for Error

impl Send for KeyUsage

impl<'a> Send for CertRevocationList<'a>

impl<'a> Send for BorrowedRevokedCert<'a>

impl<'a> Send for Cert<'a>

impl<'a> Send for EndEntityCert<'a>

impl<'a> Send for RawPublicKeyEntity<'a>

impl<'a> Send for RevocationOptions<'a>

impl<'p> Send for VerifiedPath<'p>

impl Send for Arch

impl Send for Country

impl Send for DesktopEnv

impl Send for Language

impl Send for Platform

impl Send for Width

impl Send for Endianness

impl Send for Needed

impl Send for StrContext

impl Send for EmptyError

impl Send for BStr

impl Send for Bytes

impl Send for Range

impl<'p, P, I, O, E> Send for ByRef<'p, P, I, O, E>
where P: Send, I: Send, O: Send, E: Send,

impl<'t, T> Send for TokenSlice<'t, T>
where T: Sync,

impl<C> Send for ContextError<C>
where C: Send,

impl<E> Send for ErrMode<E>
where E: Send,

impl<F, G, H, I, O, O2, E> Send for FlatMap<F, G, H, I, O, O2, E>
where F: Send, G: Send, H: Send, I: Send, O: Send, O2: Send, E: Send,

impl<F, G, I, O, O2, E> Send for AndThen<F, G, I, O, O2, E>
where F: Send, G: Send, I: Send, O: Send, O2: Send, E: Send,

impl<F, G, I, O, O2, E> Send for Map<F, G, I, O, O2, E>
where F: Send, G: Send, I: Send, O: Send, O2: Send, E: Send,

impl<F, G, I, O, O2, E> Send for Verify<F, G, I, O, O2, E>
where F: Send, G: Send, I: Send, O: Send, O2: Send + ?Sized, E: Send,

impl<F, G, I, O, O2, E> Send for VerifyMap<F, G, I, O, O2, E>
where F: Send, G: Send, I: Send, O: Send, O2: Send, E: Send,

impl<F, G, I, O, O2, E, E2> Send for TryMap<F, G, I, O, O2, E, E2>
where F: Send, G: Send, I: Send, O: Send, O2: Send, E: Send, E2: Send,

impl<F, I, O, E> Send for Span<F, I, O, E>
where F: Send, I: Send, O: Send, E: Send,

impl<F, I, O, E> Send for Take<F, I, O, E>
where F: Send, I: Send, O: Send, E: Send,

impl<F, I, O, E> Send for Void<F, I, O, E>
where F: Send, I: Send, O: Send, E: Send,

impl<F, I, O, E> Send for WithSpan<F, I, O, E>
where F: Send, I: Send, O: Send, E: Send,

impl<F, I, O, E> Send for WithTaken<F, I, O, E>
where F: Send, I: Send, O: Send, E: Send,

impl<F, I, O, E> Send for ParserIterator<F, I, O, E>
where F: Send, I: Send, E: Send, O: Send,

impl<F, I, O, E, C> Send for Context<F, I, O, E, C>
where F: Send, C: Send, I: Send, O: Send, E: Send,

impl<F, I, O, E, E2> Send for ErrInto<F, I, O, E, E2>
where F: Send, I: Send, O: Send, E: Send, E2: Send,

impl<F, I, O, O2, E> Send for DefaultValue<F, I, O, O2, E>
where F: Send, O2: Send, I: Send, O: Send, E: Send,

impl<F, I, O, O2, E> Send for OutputInto<F, I, O, O2, E>
where F: Send, I: Send, O: Send, O2: Send, E: Send,

impl<F, I, O, O2, E> Send for Value<F, I, O, O2, E>
where F: Send, O2: Send, I: Send, O: Send, E: Send,

impl<I> Send for InputError<I>
where I: Send,

impl<I> Send for TreeErrorBase<I>
where I: Send,

impl<I> Send for BitOffsets<I>
where I: Send,

impl<I> Send for LocatingSlice<I>
where I: Send,

impl<I> Send for Partial<I>
where I: Send,

impl<I, C> Send for TreeError<I, C>
where I: Send, C: Send,

impl<I, C> Send for TreeErrorFrame<I, C>
where I: Send, C: Send,

impl<I, C> Send for TreeErrorContext<I, C>
where I: Send, C: Send,

impl<I, E> Send for ParseError<I, E>
where I: Send, E: Send,

impl<I, S> Send for Stateful<I, S>
where I: Send, S: Send,

impl<P, I, O, C, E> Send for Repeat<P, I, O, C, E>
where P: Send, I: Send, O: Send, C: Send, E: Send,

impl<P, I, O, E> Send for CompleteErr<P, I, O, E>
where P: Send, I: Send, O: Send, E: Send,

impl<P, I, O, O2, E> Send for ParseTo<P, I, O, O2, E>
where P: Send, I: Send, O: Send, O2: Send, E: Send,

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

impl<T, S> Send for Checkpoint<T, S>
where T: Send, S: Send,

impl Send for Bitcast

impl Send for LiftLower

impl Send for Direction

impl Send for Files

impl Send for Source

impl Send for Ns

impl Send for TypeInfo

impl Send for Types

impl<'a> Send for Instruction<'a>

impl Send for WithOption

impl Send for MissingWith

impl Send for Opts

impl Send for TypeKind

impl Send for Bindgen

impl Send for EncodingMap

impl Send for Linker

impl<O> Send for WitPrinter<O>
where O: Send,

impl Send for AbiVariant

impl Send for WasmType

impl Send for DecodedWasm

impl Send for Alignment

impl Send for AstItem

impl Send for FlagsRepr

impl Send for Handle

impl Send for Int

impl Send for Mangling

impl Send for Results

impl Send for Stability

impl Send for Type

impl Send for TypeDefKind

impl Send for TypeOwner

impl Send for WorldItem

impl Send for WorldKey

impl Send for Case

impl Send for Docs

impl Send for ElementInfo

impl Send for Enum

impl Send for EnumCase

impl Send for Field

impl Send for Flag

impl Send for Flags

impl Send for Function

impl Send for IncludeName

impl Send for Interface

impl Send for LiveTypes

impl Send for Package

impl Send for PackageName

impl Send for Record

impl Send for Remap

impl Send for Resolve

impl Send for Result_

impl Send for SizeAlign

impl Send for SourceMap

impl Send for Tuple

impl Send for TypeDef

impl Send for Variant

impl Send for World

impl<'a> Send for ResultsTypeIter<'a>

impl<'a> Send for WasmExport<'a>

impl<'a> Send for WasmImport<'a>

impl Send for LengthHint

impl Send for Part

impl<W> Send for CoreWriteAsPartsWrite<W>
where W: Send + ?Sized,

impl Send for StreamError

impl Send for ObjectId

impl Send for Error

impl Send for Pollable

impl Send for InputStream

impl Send for ErrorCode

impl Send for HeaderError

impl Send for Method

impl Send for Scheme

impl Send for StreamError

impl Send for Fields

impl Send for Error

impl Send for Pollable

impl Send for InputStream

impl Send for Request

impl Send for Response

impl Send for HttpBody

impl<E> Send for HttpBodyError<E>
where E: Send,

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

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

impl Send for CallError

impl Send for Error

impl Send for Invocation

impl Send for StreamError

impl Send for Context

impl<'a, T, W> Send for ValEncoder<'a, T, W>
where T: Send,

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

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

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

impl Send for Decoder

impl Send for Encoder

impl Send for Frame

impl Send for Incoming

impl Send for Outgoing

impl Send for UnitCodec

impl<'a> Send for FrameRef<'a>

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

impl<C, I, O> Send for AcceptError<C, I, O>
where C: Send, I: Send, O: Send,

impl<C, I, O, H> Send for Server<C, I, O, H>
where H: Send, C: Send, I: Send, O: Send,

impl<H> Send for InvokeBuilder<H>
where H: Send + ?Sized,

impl<R> Send for StreamDecoderBytes<R>

impl<R> Send for StreamDecoderRead<R>

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

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

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

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

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

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

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

impl<T, F> Send for AcceptMapContext<T, F>
where T: Send, F: Send,

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

impl<T, R> Send for ListDecoder<T, R>
where T: Send, <T as Decoder>::Item: Send,

impl<T, R> Send for StreamDecoder<T, R>
where <T as Decode<R>>::ListDecoder: Send, T: Send,

impl<W> Send for FutureEncoder<W>

impl<W> Send for ListEncoder<W>

impl<W> Send for StreamEncoder<W>

impl<W> Send for StreamEncoderBytes<W>

impl<W> Send for StreamEncoderRead<W>

impl Send for ParamWriter

impl Send for Client

impl Send for Message

impl Send for Reader

impl Send for Subscriber

impl Send for Version

impl Send for Version

impl Send for DisplayText

impl Send for Reasons

impl Send for CrlReason

impl Send for KeyUsages

impl Send for GeneralName

impl Send for Version

impl Send for Time

impl Send for Attribute

impl Send for Rfc5280

impl Send for RevokedCert

impl Send for TbsCertList

impl Send for UserNotice

impl Send for CrlNumber

impl Send for FreshestCrl

impl Send for OtherName

impl Send for KeyUsage

impl Send for Extension

impl Send for RdnSequence

impl Send for CertReq

impl Send for CertReqInfo

impl Send for Validity

impl<P> Send for CertificateInner<P>
where P: Send,

impl<P> Send for TbsCertificateInner<P>
where P: Send,

impl<P> Send for SerialNumber<P>
where P: Send,

impl Send for PEMError

impl Send for X509Error

impl Send for Validity

impl Send for NidError

impl Send for CtVersion

impl Send for KeyUsage

impl Send for NSCertType

impl Send for ReasonFlags

impl Send for Pem

impl Send for ASN1Time

impl Send for ReasonCode

impl Send for X509Version

impl<'a> Send for ParsedCriAttribute<'a>

impl<'a> Send for DistributionPointName<'a>

impl<'a> Send for GeneralName<'a>

impl<'a> Send for ParsedExtension<'a>

impl<'a> Send for PublicKey<'a>

impl<'a> Send for SignatureAlgorithm<'a>

impl<'a> Send for TbsCertificate<'a>

impl<'a> Send for UniqueIdentifier<'a>

impl<'a> Send for X509Certificate<'a>

impl<'a> Send for ExtensionRequest<'a>

impl<'a> Send for X509CriAttribute<'a>

impl<'a> Send for AccessDescription<'a>

impl<'a> Send for AuthorityInfoAccess<'a>

impl<'a> Send for AuthorityKeyIdentifier<'a>

impl<'a> Send for CRLDistributionPoint<'a>

impl<'a> Send for CRLDistributionPoints<'a>

impl<'a> Send for CtExtensions<'a>

impl<'a> Send for CtLogID<'a>

impl<'a> Send for DigitallySigned<'a>

impl<'a> Send for ExtendedKeyUsage<'a>

impl<'a> Send for GeneralSubtree<'a>

impl<'a> Send for IssuerAlternativeName<'a>

impl<'a> Send for KeyIdentifier<'a>

impl<'a> Send for NameConstraints<'a>

impl<'a> Send for PolicyInformation<'a>

impl<'a> Send for PolicyMapping<'a>

impl<'a> Send for PolicyMappings<'a>

impl<'a> Send for PolicyQualifierInfo<'a>

impl<'a> Send for SubjectAlternativeName<'a>

impl<'a> Send for X509Extension<'a>

impl<'a> Send for ECPoint<'a>

impl<'a> Send for RSAPublicKey<'a>

impl<'a> Send for RevokedCertificate<'a>

impl<'a> Send for TbsCertList<'a>

impl<'a> Send for RsaAesOaepParams<'a>

impl<'a> Send for RsaSsaPssParams<'a>

impl<'a> Send for EcdsaSigValue<'a>

impl<'a> Send for AlgorithmIdentifier<'a>

impl<'a> Send for AttributeTypeAndValue<'a>

impl<'a> Send for SubjectPublicKeyInfo<'a>

impl<'a> Send for X509Name<'a>

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

impl<Reader> Send for PemIterator<Reader>
where Reader: Send,

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

impl Send for Event

impl Send for Xml

impl Send for Element

impl Send for EndTag

impl Send for Parser

impl Send for ParserError

impl Send for StartTag

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

impl Send for Error

impl Send for StreamError

impl Send for TextPos

impl<'a> Send for ElementEnd<'a>

impl<'a> Send for EntityDefinition<'a>

impl<'a> Send for ExternalId<'a>

impl<'a> Send for Reference<'a>

impl<'a> Send for Token<'a>

impl<'a> Send for StrSpan<'a>

impl<'a> Send for Stream<'a>

impl<'a> Send for Tokenizer<'a>

impl<C0, C1> Send for EitherCart<C0, C1>
where C0: Send, C1: Send,

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

impl<Y, C> Send for Yoke<Y, C>
where C: Send, Y: Send,

impl Send for BigEndian

impl Send for AllocError

impl<A, S, V> Send for ConvertError<A, S, V>
where A: Send, S: Send, V: Send,

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

impl<O> Send for F32<O>
where O: Send,

impl<O> Send for F64<O>
where O: Send,

impl<O> Send for I128<O>
where O: Send,

impl<O> Send for I16<O>
where O: Send,

impl<O> Send for I32<O>
where O: Send,

impl<O> Send for I64<O>
where O: Send,

impl<O> Send for Isize<O>
where O: Send,

impl<O> Send for U128<O>
where O: Send,

impl<O> Send for U16<O>
where O: Send,

impl<O> Send for U32<O>
where O: Send,

impl<O> Send for U64<O>
where O: Send,

impl<O> Send for Usize<O>
where O: Send,

impl<Src, Dst> Send for AlignmentError<Src, Dst>
where Src: Send, Dst: ?Sized,

impl<Src, Dst> Send for SizeError<Src, Dst>
where Src: Send, Dst: ?Sized,

impl<Src, Dst> Send for ValidityError<Src, Dst>
where Src: Send, Dst: ?Sized,

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

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

impl<Z> Send for Zeroizing<Z>
where Z: Send,

impl Send for CharULE

impl Send for Index16

impl Send for Index32

impl<'a> Send for FlexZeroVec<'a>

impl<'a, K, V> Send for ZeroMapBorrowed<'a, K, V>
where <K as ZeroMapKV<'a>>::Slice: Sync, <V as ZeroMapKV<'a>>::Slice: Sync, K: ?Sized, V: ?Sized,

impl<'a, K, V> Send for ZeroMap<'a, K, V>
where <K as ZeroMapKV<'a>>::Container: Send, <V as ZeroMapKV<'a>>::Container: Send, K: ?Sized, V: ?Sized,

impl<'a, K0, K1, V> Send for ZeroMap2dBorrowed<'a, K0, K1, V>
where <K0 as ZeroMapKV<'a>>::Slice: Sync, <K1 as ZeroMapKV<'a>>::Slice: Sync, <V as ZeroMapKV<'a>>::Slice: Sync, K0: ?Sized, K1: ?Sized, V: ?Sized,

impl<'a, K0, K1, V> Send for ZeroMap2d<'a, K0, K1, V>
where <K0 as ZeroMapKV<'a>>::Container: Send, <K1 as ZeroMapKV<'a>>::Container: Send, <V as ZeroMapKV<'a>>::Container: Send, K0: ?Sized, K1: ?Sized, V: ?Sized,

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

impl<'l, 'a, K0, K1, V> Send for ZeroMap2dCursor<'l, 'a, K0, K1, V>
where <K0 as ZeroMapKV<'a>>::Slice: Sync, <K1 as ZeroMapKV<'a>>::Slice: Sync, <V as ZeroMapKV<'a>>::Slice: Sync, K0: ?Sized, K1: ?Sized, V: ?Sized,

impl<A, B> Send for Tuple2ULE<A, B>
where A: Send, B: Send,

impl<A, B, C> Send for Tuple3ULE<A, B, C>
where A: Send, B: Send, C: Send,

impl<A, B, C, D> Send for Tuple4ULE<A, B, C, D>
where A: Send, B: Send, C: Send, D: Send,

impl<A, B, C, D, E> Send for Tuple5ULE<A, B, C, D, E>
where A: Send, B: Send, C: Send, D: Send, E: Send,

impl<A, B, C, D, E, F> Send for Tuple6ULE<A, B, C, D, E, F>
where A: Send, B: Send, C: Send, D: Send, E: Send, F: Send,

impl<T> Send for ZeroSlice<T>
where <T as AsULE>::ULE: Send,

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

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

impl<U> Send for OptionULE<U>
where U: Send,

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

impl<U, const N: usize> Send for NichedOption<U, N>
where U: Send,

impl<U, const N: usize> Send for NichedOptionULE<U, N>
where U: Send,

impl<const N: usize> Send for RawBytesULE<N>

impl Send for NoOp

impl Send for Status

impl<'a> Send for Compressor<'a>

impl<'a> Send for Decompressor<'a>

impl<'a> Send for DecoderDictionary<'a>

impl<'a> Send for EncoderDictionary<'a>

impl<'a> Send for Decoder<'a>

impl<'a> Send for Encoder<'a>

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

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

impl<'a, W> Send for Decoder<'a, W>
where W: Send,

impl<'a, W> Send for Encoder<'a, W>
where W: Send,

impl<'a, W, F> Send for AutoFinishEncoder<'a, W, F>
where F: Send, W: Send,

impl<'a, W, F> Send for AutoFlushDecoder<'a, W, F>
where F: Send, W: Send,

impl<R, D> Send for Reader<R, D>
where R: Send, D: Send,

impl<W, D> Send for Writer<W, D>
where D: Send, W: Send,

impl Send for CParameter

impl Send for DParameter

impl<'a> Send for InBuffer<'a>

impl<'a, C> Send for OutBuffer<'a, C>
where C: Send + ?Sized,

impl Send for ZSTD_CCtx_s

impl Send for ZSTD_DCtx_s

impl Send for ZSTD_bounds