Trait wasmer_types::lib::std::marker::Send

1.0.0 · source ·
pub unsafe auto trait Send { }
Available on crate feature std only.
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§

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 SharedDeserializeMapError

source§

impl Send for AllocScratchError

source§

impl Send for SharedSerializeMapError

source§

impl Send for ArchiveError

1.6.0 · source§

impl Send for wasmer_types::lib::std::string::Drain<'_>

1.36.0 · source§

impl Send for Waker

1.63.0 · source§

impl Send for BorrowedHandle<'_>

1.63.0 · source§

impl Send for HandleOrInvalid

1.63.0 · source§

impl Send for HandleOrNull

1.63.0 · source§

impl Send for OwnedHandle

source§

impl Send for bytes::bytes::Bytes

source§

impl Send for BytesMut

source§

impl Send for AllocScratch

source§

impl Send for SharedSerializeMap

source§

impl Send for AlignedVec

source§

impl Send for PrefixRange

source§

impl Send for SuffixRange

source§

impl Send for SharedValidator

1.44.0 · source§

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

1.44.0 · source§

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

source§

impl<'a> Send for ArchiveValidator<'a>

source§

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

source§

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

source§

impl<Dyn> Send for wasmer_types::lib::std::ptr::DynMetadata<Dyn>
where Dyn: ?Sized,

source§

impl<Dyn> Send for ptr_meta::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> 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 + Clone,

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

source§

impl<K, V, S, A> Send for hashbrown::map::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,

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

source§

impl<T> !Send for ReentrantLockGuard<'_, 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,

1.0.0 · source§

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

source§

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

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

1.0.0 · source§

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

1.0.0 · source§

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

1.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 wasmer_types::lib::std::slice::Iter<'_, T>
where T: Sync,

1.0.0 · source§

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

1.31.0 · source§

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

1.31.0 · source§

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

1.0.0 · source§

impl<T> Send for AtomicPtr<T>

Available on target_has_atomic_load_store="ptr" only.
1.0.0 · source§

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

1.0.0 · source§

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

1.0.0 · source§

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

1.0.0 · source§

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

1.70.0 · source§

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

source§

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

1.0.0 · source§

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

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,

1.28.0 · source§

impl<T> Send for NonZero<T>

1.29.0 · source§

impl<T> Send for JoinHandle<T>

source§

impl<T> Send for hashbrown::raw::inner::Bucket<T>

source§

impl<T> Send for hashbrown::raw::inner::Bucket<T>

source§

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

source§

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

1.0.0 · source§

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

1.4.0 · source§

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

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 wasmer_types::lib::std::sync::Weak<T, A>
where T: Sync + Send + ?Sized, A: Allocator + Send,

1.6.0 · source§

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

1.0.0 · source§

impl<T, A> Send for wasmer_types::lib::std::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,

source§

impl<T, A> Send for hashbrown::raw::inner::RawDrain<'_, T, A>
where A: Allocator + Copy + Send, T: Send,

source§

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

source§

impl<T, A> Send for hashbrown::raw::inner::RawIntoIter<T, A>
where A: Allocator + Clone + Send, T: Send,

source§

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

source§

impl<T, A> Send for hashbrown::raw::inner::RawTable<T, A>
where A: Allocator + Clone + Send, T: Send,

source§

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

source§

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

source§

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

Auto implementors§

§

impl !Send for OnceState

§

impl Send for RelocationKind

§

impl Send for RelocationKindResolver

§

impl Send for RelocationTarget

§

impl Send for RelocationTargetResolver

§

impl Send for CustomSectionProtection

§

impl Send for CustomSectionProtectionResolver

§

impl Send for Symbol

§

impl Send for SymbolResolver

§

impl Send for CpuFeature

§

impl Send for ArchivedCompiledFunctionUnwindInfo

§

impl Send for CompiledFunctionUnwindInfo

§

impl Send for CompiledFunctionUnwindInfoResolver

§

impl Send for Aarch64Architecture

§

impl Send for Architecture

§

impl Send for BinaryFormat

§

impl Send for CallingConvention

§

impl Send for Endianness

§

impl Send for Environment

§

impl Send for ExportIndex

§

impl Send for ExternType

§

impl Send for GlobalInit

§

impl Send for HashAlgorithm

§

impl Send for ImportIndex

§

impl Send for LibCall

§

impl Send for MemoryStyle

§

impl Send for ModuleHash

§

impl Send for Mutability

§

impl Send for OnCalledAction

§

impl Send for OperatingSystem

§

impl Send for PointerWidth

§

impl Send for TableStyle

§

impl Send for TrapCode

§

impl Send for Type

§

impl Send for Vendor

§

impl Send for CompileError

§

impl Send for DeserializeError

§

impl Send for ImportError

§

impl Send for MemoryError

§

impl Send for ParseCpuFeatureError

§

impl Send for PreInstantiationError

§

impl Send for SerializeError

§

impl Send for WasmError

§

impl Send for wasmer_types::lib::std::cmp::Ordering

§

impl Send for Infallible

§

impl Send for wasmer_types::lib::std::fmt::Alignment

§

impl Send for wasmer_types::lib::std::sync::atomic::Ordering

§

impl Send for RecvTimeoutError

§

impl Send for TryRecvError

§

impl Send for ArchivedFunctionAddressMap

§

impl Send for ArchivedInstructionAddressMap

§

impl Send for FunctionAddressMap

§

impl Send for FunctionAddressMapResolver

§

impl Send for InstructionAddressMap

§

impl Send for InstructionAddressMapResolver

§

impl Send for ArchivedCompiledFunction

§

impl Send for ArchivedCompiledFunctionFrameInfo

§

impl Send for ArchivedFunctionBody

§

impl Send for Compilation

§

impl Send for CompiledFunction

§

impl Send for CompiledFunctionFrameInfo

§

impl Send for CompiledFunctionFrameInfoResolver

§

impl Send for CompiledFunctionResolver

§

impl Send for Dwarf

§

impl Send for DwarfResolver

§

impl Send for FunctionBody

§

impl Send for FunctionBodyResolver

§

impl Send for ArchivedCompileModuleInfo

§

impl Send for CompileModuleInfo

§

impl Send for CompileModuleInfoResolver

§

impl Send for ArchivedRelocation

§

impl Send for Relocation

§

impl Send for RelocationResolver

§

impl Send for ArchivedCustomSection

§

impl Send for ArchivedSectionBody

§

impl Send for CustomSection

§

impl Send for CustomSectionResolver

§

impl Send for SectionBody

§

impl Send for SectionBodyResolver

§

impl Send for SectionIndex

§

impl Send for SectionIndexResolver

§

impl Send for ArchivedModuleMetadata

§

impl Send for ModuleMetadata

§

impl Send for ModuleMetadataResolver

§

impl Send for ModuleMetadataSymbolRegistry

§

impl Send for Target

§

impl Send for MiddlewareError

§

impl Send for ArchivedDataInitializerLocation

§

impl Send for ArchivedOwnedDataInitializer

§

impl Send for ArchivedSerializableCompilation

§

impl Send for ArchivedSerializableModule

§

impl Send for wasmer_types::Bytes

§

impl Send for CustomSectionIndex

§

impl Send for DataIndex

§

impl Send for DataInitializerLocation

§

impl Send for ElemIndex

§

impl Send for Features

§

impl Send for FrameInfo

§

impl Send for FunctionIndex

§

impl Send for FunctionType

§

impl Send for GlobalIndex

§

impl Send for GlobalType

§

impl Send for ImportKey

§

impl Send for LocalFunctionIndex

§

impl Send for LocalGlobalIndex

§

impl Send for LocalMemoryIndex

§

impl Send for LocalTableIndex

§

impl Send for Memory32

§

impl Send for Memory64

§

impl Send for MemoryIndex

§

impl Send for MemoryType

§

impl Send for MetadataHeader

§

impl Send for ModuleInfo

§

impl Send for OwnedDataInitializer

§

impl Send for PageCountOutOfRange

§

impl Send for Pages

§

impl Send for SerializableCompilation

§

impl Send for SerializableModule

§

impl Send for SignatureIndex

§

impl Send for SourceLoc

§

impl Send for StoreId

§

impl Send for TableIndex

§

impl Send for TableInitializer

§

impl Send for TableType

§

impl Send for TargetSharedSignatureIndex

§

impl Send for TrapInformation

§

impl Send for Triple

§

impl Send for V128

§

impl Send for VMBuiltinFunctionIndex

§

impl Send for VMOffsets

§

impl Send for TypeId

§

impl Send for BorrowError

§

impl Send for BorrowMutError

§

impl Send for Error

§

impl Send for DefaultHasher

§

impl Send for RandomState

§

impl Send for SipHasher

§

impl Send for Assume

§

impl Send for RangeFull

§

impl Send for wasmer_types::lib::std::ptr::Alignment

§

impl Send for FromUtf8Error

§

impl Send for FromUtf16Error

§

impl Send for String

§

impl Send for AtomicBool

§

impl Send for AtomicI8

§

impl Send for AtomicI16

§

impl Send for AtomicI32

§

impl Send for AtomicI64

§

impl Send for AtomicI128

§

impl Send for AtomicIsize

§

impl Send for AtomicU8

§

impl Send for AtomicU16

§

impl Send for AtomicU32

§

impl Send for AtomicU64

§

impl Send for AtomicU128

§

impl Send for AtomicUsize

§

impl Send for RecvError

§

impl Send for Barrier

§

impl Send for BarrierWaitResult

§

impl Send for Condvar

§

impl Send for wasmer_types::lib::std::sync::Once

§

impl Send for WaitTimeoutResult

§

impl Send for PhantomPinned

§

impl Send for RawValue

§

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

§

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

§

impl<'a> Send for CompiledFunctionUnwindInfoReference<'a>

§

impl<'a> Send for EscapeAscii<'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 Cow<'a, B>
where <B as ToOwned>::Owned: Send, B: Sync + ?Sized,

§

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 wasmer_types::entity::Iter<'a, K, V>
where K: Send, V: Sync,

§

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

§

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

§

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

§

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 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 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 Split<'a, T, P>
where P: Send, T: Sync,

§

impl<'a, T, P> Send for 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 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 wasmer_types::lib::std::slice::ArrayChunks<'a, T, N>
where T: Sync,

§

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

§

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

§

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

§

impl<'data> Send for DataInitializer<'data>

§

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

§

impl<A> Send for RepeatN<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<F> Send for FormatterFn<F>
where F: Send,

§

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

§

impl<I> Send for ImportsIterator<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 wasmer_types::lib::std::iter::ArrayChunks<I, N>
where I: Send, <I as Iterator>::Item: Send,

§

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

§

impl<Idx> Send for RangeFrom<Idx>
where Idx: Send,

§

impl<Idx> Send for RangeInclusive<Idx>
where Idx: Send,

§

impl<Idx> Send for RangeTo<Idx>
where Idx: Send,

§

impl<Idx> Send for RangeToInclusive<Idx>
where Idx: Send,

§

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

§

impl<K, V> !Send for ArchivedPrimaryMap<K, V>

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<T> Send for wasmer_types::lib::std::iter::Once<T>
where T: Send,

§

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

§

impl<T> Send for Discriminant<T>

§

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

§

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

§

impl<T> Send for wasmer_types::lib::std::sync::mpsc::IntoIter<T>
where T: Send,

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<Y, R> Send for CoroutineState<Y, R>
where Y: Send, R: Send,