devela::all

Trait Send

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

core 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

1.0.0 · Source§

impl !Send for Arguments<'_>

§

impl Send for RawId

Source§

impl Send for ExampleEnumIntU8

Available on doc only.
Source§

impl Send for devela::_core::ffi::c_str::Bytes<'_>

1.6.0 · Source§

impl Send for devela::_dep::_alloc::string::Drain<'_>

§

impl Send for Bump

§

impl Send for PyBackedBytes

§

impl Send for PyBackedStr

§

impl Send for Arena

§

impl Send for ArenaHandle<'_>

§

impl Send for devela::_dep::rodio::cpal::platform::AlsaDevices

1.36.0 · Source§

impl Send for Waker

§

impl Send for Bytes

§

impl Send for BytesMut

§

impl Send for ClientInfo

§

impl Send for Collector

§

impl Send for Ctl

§

impl Send for ElemId

§

impl Send for HCtl

§

impl Send for Mixer

§

impl Send for Output

§

impl Send for PCM

§

impl Send for Parker

§

impl Send for PortInfo

§

impl Send for PortSubscribe

§

impl Send for QueueStatus

§

impl Send for QueueTempo

§

impl Send for Rawmidi

§

impl Send for RemoveEvents

§

impl Send for Seq

§

impl Send for Unparker

1.44.0 · Source§

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

1.44.0 · Source§

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

§

impl<'a> Send for Event<'a>

§

impl<'a, 'bump> Send for devela::_dep::bumpalo::collections::string::Drain<'a, 'bump>

§

impl<'a, 'bump, T> Send for devela::_dep::bumpalo::collections::vec::Drain<'a, 'bump, T>
where T: Send,

§

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

§

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

§

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

§

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

Source§

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

§

impl<'bump, T> Send for devela::_dep::bumpalo::collections::vec::IntoIter<'bump, T>
where T: Send,

§

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

Source§

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

§

impl<Dyn> Send for devela::_dep::rkyv::ptr_meta::DynMetadata<Dyn>
where Dyn: ?Sized,

§

impl<K, V> Send for devela::_dep::hashbrown::hash_map::IterMut<'_, K, V>
where K: Send, V: Send,

§

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

§

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

§

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

§

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

§

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

§

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

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,

Source§

impl<T> !Send for devela::_dep::_std::sync::MappedMutexGuard<'_, T>
where T: ?Sized,

Source§

impl<T> !Send for devela::_dep::_std::sync::MappedRwLockReadGuard<'_, T>
where T: ?Sized,

Source§

impl<T> !Send for devela::_dep::_std::sync::MappedRwLockWriteGuard<'_, T>
where T: ?Sized,

Source§

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

1.0.0 · Source§

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

1.0.0 · Source§

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

1.31.0 · Source§

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

1.0.0 · Source§

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

1.0.0 · Source§

impl<T> Send for devela::_core::slice::Iter<'_, T>
where T: Sync,

1.0.0 · Source§

impl<T> Send for devela::_core::slice::IterMut<'_, T>
where T: Send,

1.31.0 · Source§

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

1.31.0 · Source§

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

1.0.0 · Source§

impl<T> Send for devela::_core::sync::atomic::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 devela::_dep::_alloc::collections::linked_list::Iter<'_, T>
where T: Sync,

1.0.0 · Source§

impl<T> Send for devela::_dep::_alloc::collections::linked_list::IterMut<'_, T>
where T: Send,

Source§

impl<T> Send for devela::_dep::_std::sync::mpmc::Receiver<T>
where T: Send,

Source§

impl<T> Send for devela::_dep::_std::sync::mpmc::Sender<T>
where T: Send,

1.0.0 · Source§

impl<T> Send for devela::_dep::_std::sync::mpsc::Receiver<T>
where T: Send,

1.0.0 · Source§

impl<T> Send for devela::_dep::_std::sync::mpsc::Sender<T>
where T: Send,

1.0.0 · Source§

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

Source§

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

§

impl<T> Send for PyBuffer<T>

§

impl<T> Send for Py<T>

§

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

§

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

§

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

§

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

1.0.0 · Source§

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

1.70.0 · Source§

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

1.0.0 · Source§

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

1.29.0 · Source§

impl<T> Send for JoinHandle<T>

1.0.0 · Source§

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

1.28.0 · Source§

impl<T> Send for NonZero<T>

1.0.0 · Source§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

Source§

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

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 devela::all::RcWeak<T, A>
where A: Allocator, T: ?Sized,

Source§

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

Source§

impl<T, A> Send for devela::_dep::_alloc::collections::linked_list::CursorMut<'_, T, A>
where T: Send, A: Allocator + Send,

1.6.0 · Source§

impl<T, A> Send for devela::_dep::_alloc::collections::vec_deque::Drain<'_, T, A>
where T: Send, A: Allocator + Send,

1.6.0 · Source§

impl<T, A> Send for devela::_dep::_alloc::vec::Drain<'_, T, A>
where T: Send, A: Send + Allocator,

1.0.0 · Source§

impl<T, A> Send for devela::_dep::_alloc::vec::IntoIter<T, A>
where T: Send, A: Allocator + Send,

§

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

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 devela::work::ArcWeak<T, A>
where T: Sync + Send + ?Sized, A: Allocator + Send,

1.0.0 · Source§

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

§

impl<T, const N: usize> Send for InlineVec<T, N>
where T: Send,

Source§

impl<T: Send> Send for BareBox<T>

Available on crate feature unsafe_sync only.
Source§

impl<T: Send> Send for CacheAlign<T>

Available on crate feature unsafe_sync only.
§

impl<const A: usize> Send for AlignedVec<A>

Auto implementors§

§

impl !Send for PoolingState

§

impl !Send for Vars

§

impl !Send for VarsOs

§

impl !Send for BoxBytes

§

impl !Send for Collator

§

impl !Send for DateTimeFormat

§

impl !Send for NumberFormat

§

impl !Send for PluralRules

§

impl !Send for RelativeTimeFormat

§

impl !Send for CompileError

§

impl !Send for Exception

§

impl !Send for devela::_dep::js_sys::WebAssembly::Global

§

impl !Send for Instance

§

impl !Send for LinkError

§

impl !Send for Memory

§

impl !Send for Module

§

impl !Send for RuntimeError

§

impl !Send for Table

§

impl !Send for devela::_dep::js_sys::WebAssembly::Tag

§

impl !Send for devela::_dep::js_sys::Array

§

impl !Send for ArrayBuffer

§

impl !Send for ArrayIntoIter

§

impl !Send for AsyncIterator

§

impl !Send for BigInt64Array

§

impl !Send for BigInt

§

impl !Send for BigUint64Array

§

impl !Send for Boolean

§

impl !Send for DataView

§

impl !Send for devela::_dep::js_sys::Date

§

impl !Send for devela::_dep::js_sys::Error

§

impl !Send for EvalError

§

impl !Send for Float32Array

§

impl !Send for Float64Array

§

impl !Send for devela::_dep::js_sys::Function

§

impl !Send for Generator

§

impl !Send for Int8Array

§

impl !Send for Int16Array

§

impl !Send for Int32Array

§

impl !Send for devela::_dep::js_sys::IntoIter

§

impl !Send for Iterator

§

impl !Send for IteratorNext

§

impl !Send for JsString

§

impl !Send for devela::_dep::js_sys::Map

§

impl !Send for devela::_dep::js_sys::Number

§

impl !Send for Object

§

impl !Send for Promise

§

impl !Send for Proxy

§

impl !Send for RangeError

§

impl !Send for ReferenceError

§

impl !Send for RegExp

§

impl !Send for Set

§

impl !Send for SharedArrayBuffer

§

impl !Send for Symbol

§

impl !Send for SyntaxError

§

impl !Send for TypeError

§

impl !Send for Uint8Array

§

impl !Send for Uint8ClampedArray

§

impl !Send for Uint16Array

§

impl !Send for Uint32Array

§

impl !Send for UriError

§

impl !Send for WeakMap

§

impl !Send for WeakSet

§

impl !Send for file_dedupe_range_t

§

impl !Send for iovec_t

§

impl !Send for ipc_kludge_t

§

impl !Send for mmsghdr_t

§

impl !Send for msghdr_t

§

impl !Send for perf_event_query_bpf_t

§

impl !Send for prctl_mm_map_t

§

impl !Send for robust_list_head_t

§

impl !Send for robust_list_t

§

impl !Send for serial_struct_t

§

impl !Send for sysctl_args_t

§

impl !Send for CancelledError

§

impl !Send for IncompleteReadError

§

impl !Send for InvalidStateError

§

impl !Send for LimitOverrunError

§

impl !Send for QueueEmpty

§

impl !Send for QueueFull

§

impl !Send for TimeoutError

§

impl !Send for gaierror

§

impl !Send for herror

§

impl !Send for timeout

§

impl !Send for PyArithmeticError

§

impl !Send for PyAssertionError

§

impl !Send for PyAttributeError

§

impl !Send for PyBaseException

§

impl !Send for PyBlockingIOError

§

impl !Send for PyBrokenPipeError

§

impl !Send for PyBufferError

§

impl !Send for PyBytesWarning

§

impl !Send for PyChildProcessError

§

impl !Send for PyConnectionAbortedError

§

impl !Send for PyConnectionError

§

impl !Send for PyConnectionRefusedError

§

impl !Send for PyConnectionResetError

§

impl !Send for PyDeprecationWarning

§

impl !Send for PyEOFError

§

impl !Send for PyEncodingWarning

§

impl !Send for PyEnvironmentError

§

impl !Send for PyException

§

impl !Send for PyFileExistsError

§

impl !Send for PyFileNotFoundError

§

impl !Send for PyFloatingPointError

§

impl !Send for PyFutureWarning

§

impl !Send for PyGeneratorExit

§

impl !Send for PyIOError

§

impl !Send for PyImportError

§

impl !Send for PyImportWarning

§

impl !Send for PyIndexError

§

impl !Send for PyInterruptedError

§

impl !Send for PyIsADirectoryError

§

impl !Send for PyKeyError

§

impl !Send for PyKeyboardInterrupt

§

impl !Send for PyLookupError

§

impl !Send for PyMemoryError

§

impl !Send for PyModuleNotFoundError

§

impl !Send for PyNameError

§

impl !Send for PyNotADirectoryError

§

impl !Send for PyNotImplementedError

§

impl !Send for PyOSError

§

impl !Send for PyOverflowError

§

impl !Send for PyPendingDeprecationWarning

§

impl !Send for PyPermissionError

§

impl !Send for PyProcessLookupError

§

impl !Send for PyRecursionError

§

impl !Send for PyReferenceError

§

impl !Send for PyResourceWarning

§

impl !Send for PyRuntimeError

§

impl !Send for PyRuntimeWarning

§

impl !Send for PyStopAsyncIteration

§

impl !Send for PyStopIteration

§

impl !Send for PySyntaxError

§

impl !Send for PySyntaxWarning

§

impl !Send for PySystemError

§

impl !Send for PySystemExit

§

impl !Send for PyTimeoutError

§

impl !Send for PyTypeError

§

impl !Send for PyUnboundLocalError

§

impl !Send for PyUnicodeDecodeError

§

impl !Send for PyUnicodeEncodeError

§

impl !Send for PyUnicodeError

§

impl !Send for PyUnicodeTranslateError

§

impl !Send for PyUnicodeWarning

§

impl !Send for PyUserWarning

§

impl !Send for PyValueError

§

impl !Send for PyWarning

§

impl !Send for PyZeroDivisionError

§

impl !Send for PyASCIIObject

§

impl !Send for PyBaseExceptionObject

§

impl !Send for PyByteArrayObject

§

impl !Send for PyBytesObject

§

impl !Send for PyCFunctionObject

§

impl !Send for PyCMethodObject

§

impl !Send for PyCodeObject

§

impl !Send for PyCompactUnicodeObject

§

impl !Send for PyComplexObject

§

impl !Send for PyConfig

§

impl !Send for PyDateTime_CAPI

§

impl !Send for PyDateTime_Date

§

impl !Send for PyDateTime_DateTime

§

impl !Send for PyDateTime_Delta

§

impl !Send for PyDateTime_Time

§

impl !Send for PyDescrObject

§

impl !Send for PyDictObject

§

impl !Send for PyFloatObject

§

impl !Send for PyFrameObject

§

impl !Send for PyFunctionObject

§

impl !Send for PyGenObject

§

impl !Send for PyGetSetDef

§

impl !Send for PyGetSetDescrObject

§

impl !Send for PyHash_FuncDef

§

impl !Send for PyHeapTypeObject

§

impl !Send for PyImportErrorObject

§

impl !Send for PyListObject

§

impl !Send for PyMemAllocatorEx

§

impl !Send for PyMemberDef

§

impl !Send for PyMemberDescrObject

§

impl !Send for devela::_dep::pyo3::ffi::PyMethodDef

§

impl !Send for PyMethodDescrObject

§

impl !Send for PyModuleDef

§

impl !Send for PyModuleDef_Base

§

impl !Send for PyModuleDef_Slot

§

impl !Send for PyNumberMethods

§

impl !Send for PyOSErrorObject

§

impl !Send for PyObject

§

impl !Send for PyObjectArenaAllocator

§

impl !Send for PySequenceMethods

§

impl !Send for PySetObject

§

impl !Send for PySliceObject

§

impl !Send for PyStatus

§

impl !Send for PyStopIterationObject

§

impl !Send for PyStructSequence_Desc

§

impl !Send for PyStructSequence_Field

§

impl !Send for PySyntaxErrorObject

§

impl !Send for PySystemExitObject

§

impl !Send for PyTupleObject

§

impl !Send for PyTypeObject

§

impl !Send for PyType_Slot

§

impl !Send for PyType_Spec

§

impl !Send for PyUnicodeErrorObject

§

impl !Send for PyUnicodeObject

§

impl !Send for PyVarObject

§

impl !Send for PyWideStringList

§

impl !Send for PyWrapperDescrObject

§

impl !Send for Py_buffer

§

impl !Send for _PyDateTime_BaseDateTime

§

impl !Send for _PyDateTime_BaseTime

§

impl !Send for _PyErr_StackItem

§

impl !Send for _PyWeakReference

§

impl !Send for _frozen

§

impl !Send for _inittab

§

impl !Send for setentry

§

impl !Send for wrapperbase

§

impl !Send for PanicException

§

impl !Send for PyAny

§

impl !Send for PyBool

§

impl !Send for PyByteArray

§

impl !Send for PyBytes

§

impl !Send for PyCFunction

§

impl !Send for PyCapsule

§

impl !Send for PyCode

§

impl !Send for PyComplex

§

impl !Send for PyDate

§

impl !Send for PyDateTime

§

impl !Send for PyDelta

§

impl !Send for PyDict

§

impl !Send for PyDictItems

§

impl !Send for PyDictKeys

§

impl !Send for PyDictValues

§

impl !Send for PyEllipsis

§

impl !Send for PyFloat

§

impl !Send for PyFrame

§

impl !Send for PyFrozenSet

§

impl !Send for PyFunction

§

impl !Send for PyInt

§

impl !Send for PyIterator

§

impl !Send for PyList

§

impl !Send for PyMapping

§

impl !Send for PyMappingProxy

§

impl !Send for PyMemoryView

§

impl !Send for PyModule

§

impl !Send for PyNone

§

impl !Send for PyNotImplemented

§

impl !Send for PySequence

§

impl !Send for PySet

§

impl !Send for PySlice

§

impl !Send for PyString

§

impl !Send for PySuper

§

impl !Send for PyTime

§

impl !Send for PyTraceback

§

impl !Send for PyTuple

§

impl !Send for PyType

§

impl !Send for PyTzInfo

§

impl !Send for PyWeakref

§

impl !Send for PyWeakrefProxy

§

impl !Send for PyWeakrefReference

§

impl !Send for FnContext

§

impl !Send for ErasedPtr

§

impl !Send for Pool

§

impl !Send for Data

§

impl !Send for devela::_dep::rodio::cpal::Stream

§

impl !Send for OutputStream

§

impl !Send for EventVec

§

impl !Send for devela::_dep::rustix::io_uring::EpollEvent

§

impl !Send for io_uring_cqe

§

impl !Send for io_uring_ptr

§

impl !Send for io_uring_sqe

§

impl !Send for iovec

§

impl !Send for msghdr

§

impl !Send for sockaddr

§

impl !Send for __kernel_sockaddr_storage

§

impl !Send for PrctlMmMap

§

impl !Send for WaitidStatus

§

impl !Send for EnteredSpan

§

impl !Send for JsError

§

impl !Send for JsValue

§

impl !Send for RawWaker

§

impl !Send for FatPtr

§

impl !Send for semun_t

§

impl !Send for PyMethodDefPointer

§

impl !Send for PyUnicodeObjectData

§

impl !Send for EventData

§

impl !Send for addr_or_splice_off_in_union

§

impl !Send for io_uring_user_data

§

impl !Send for off_or_addr2_union

§

impl !Send for IPowModulo

§

impl !Send for MaybeRuntimePyMethodDef

§

impl !Send for ModuleDef

§

impl !Send for PyClassDictSlot

§

impl !Send for PyClassItems

§

impl !Send for PyClassWeakRefSlot

§

impl !Send for PyMethodDefType

§

impl !Send for StartupTlsInfo

§

impl Send for devela::_core::ascii::Char

§

impl Send for DebugAsHex

§

impl Send for devela::_core::fmt::Sign

§

impl Send for BasicBlock

§

impl Send for UnwindTerminateReason

§

impl Send for IpAddr

§

impl Send for Ipv6MulticastScope

§

impl Send for devela::_core::net::SocketAddr

§

impl Send for GetManyMutError

§

impl Send for SearchStep

§

impl Send for TryReserveErrorKind

§

impl Send for VarError

§

impl Send for devela::_dep::_std::io::SeekFrom

§

impl Send for devela::_dep::_std::net::Shutdown

§

impl Send for AncillaryError

§

impl Send for BacktraceStyle

§

impl Send for RecvTimeoutError

§

impl Send for TryRecvError

§

impl Send for CollectionAllocErr

§

impl Send for CheckedCastError

§

impl Send for PodCastError

§

impl Send for SetCursorStyle

§

impl Send for devela::_dep::crossterm::event::Event

§

impl Send for devela::_dep::crossterm::event::KeyCode

§

impl Send for KeyEventKind

§

impl Send for MediaKeyCode

§

impl Send for ModifierKeyCode

§

impl Send for devela::_dep::crossterm::event::MouseButton

§

impl Send for MouseEventKind

§

impl Send for Attribute

§

impl Send for devela::_dep::crossterm::style::Color

§

impl Send for Colored

§

impl Send for ClearType

§

impl Send for devela::_dep::hashbrown::TryReserveError

§

impl Send for Era

§

impl Send for devela::_dep::jiff::civil::Weekday

§

impl Send for RoundMode

§

impl Send for Unit

§

impl Send for Designator

§

impl Send for devela::_dep::jiff::fmt::friendly::Direction

§

impl Send for FractionalUnit

§

impl Send for Spacing

§

impl Send for Meridiem

§

impl Send for PiecesOffset

§

impl Send for AmbiguousOffset

§

impl Send for Disambiguation

§

impl Send for Dst

§

impl Send for OffsetConflict

§

impl Send for devela::_dep::kira::backend::cpal::Error

§

impl Send for ClockSpeed

§

impl Send for DistortionKind

§

impl Send for EqFilterKind

§

impl Send for devela::_dep::kira::effect::filter::FilterMode

§

impl Send for Easing

§

impl Send for StartTime

§

impl Send for WhenToStart

§

impl Send for Waveform

§

impl Send for EndPosition

§

impl Send for FromFileError

§

impl Send for PlaybackPosition

§

impl Send for PlaybackState

§

impl Send for TrackPlaybackState

§

impl Send for devela::_dep::log::Level

§

impl Send for devela::_dep::log::LevelFilter

§

impl Send for PrefilterConfig

§

impl Send for ConnectErrorKind

§

impl Send for Ignore

§

impl Send for PortInfoError

§

impl Send for devela::_dep::midir::SendError

§

impl Send for AppleGfxApi

§

impl Send for LinuxBackend

§

impl Send for LinuxX11Gl

§

impl Send for WebGLVersion

§

impl Send for Backend

§

impl Send for BlendFactor

§

impl Send for BlendValue

§

impl Send for BufferType

§

impl Send for BufferUsage

§

impl Send for CompareFunc

§

impl Send for Comparison

§

impl Send for CullFace

§

impl Send for CursorIcon

§

impl Send for Equation

§

impl Send for devela::_dep::miniquad::FilterMode

§

impl Send for FrontFaceOrder

§

impl Send for devela::_dep::miniquad::KeyCode

§

impl Send for MipmapFilterMode

§

impl Send for devela::_dep::miniquad::MouseButton

§

impl Send for PassAction

§

impl Send for PrimitiveType

§

impl Send for ShaderError

§

impl Send for ShaderType

§

impl Send for StencilOp

§

impl Send for TextureAccess

§

impl Send for TextureFormat

§

impl Send for TextureKind

§

impl Send for TextureWrap

§

impl Send for TouchPhase

§

impl Send for UniformType

§

impl Send for VertexFormat

§

impl Send for VertexStep

§

impl Send for devela::_dep::miniquad::fs::Error

§

impl Send for IOURING_OP

§

impl Send for perf_bpf_event_type_t

§

impl Send for perf_branch_sample_type_shift_t

§

impl Send for perf_branch_sample_type_t

§

impl Send for perf_callchain_context_t

§

impl Send for perf_event_read_format_t

§

impl Send for perf_event_sample_format_t

§

impl Send for perf_event_type_t

§

impl Send for perf_hw_cache_id_t

§

impl Send for perf_hw_cache_op_id_t

§

impl Send for perf_hw_cache_op_result_id_t

§

impl Send for perf_hw_id_t

§

impl Send for perf_record_ksymbol_type_t

§

impl Send for perf_sample_regs_abi_t

§

impl Send for perf_sw_ids_t

§

impl Send for perf_type_id_t

§

impl Send for ElementType

§

impl Send for PyGILState_STATE

§

impl Send for PyMemAllocatorDomain

§

impl Send for PySendResult

§

impl Send for _PyStatus_TYPE

§

impl Send for CompareOp

§

impl Send for Associativity

§

impl Send for CacheInfoType

§

impl Send for CacheType

§

impl Send for DatType

§

impl Send for ExtendedRegisterStateLocation

§

impl Send for ExtendedRegisterType

§

impl Send for Hypervisor

§

impl Send for SgxSectionInfo

§

impl Send for TopologyType

§

impl Send for Yield

§

impl Send for Panic

§

impl Send for ArchivedIpAddr

§

impl Send for ArchivedSocketAddr

§

impl Send for OptionBoxResolver

§

impl Send for SharingState

§

impl Send for ValidationState

§

impl Send for BufferSize

§

impl Send for BuildStreamError

§

impl Send for DefaultStreamConfigError

§

impl Send for DeviceNameError

§

impl Send for HostId

§

impl Send for PauseStreamError

§

impl Send for PlayStreamError

§

impl Send for devela::_dep::rodio::cpal::SampleFormat

§

impl Send for devela::_dep::rodio::cpal::StreamError

§

impl Send for SupportedBufferSize

§

impl Send for SupportedStreamConfigsError

§

impl Send for DeviceInner

§

impl Send for DevicesInner

§

impl Send for HostInner

§

impl Send for StreamInner

§

impl Send for DecoderError

§

impl Send for Mp4Type

§

impl Send for devela::_dep::rodio::decoder::symphonia::SeekError

§

impl Send for DevicesError

§

impl Send for PlayError

§

impl Send for devela::_dep::rodio::StreamError

§

impl Send for devela::_dep::rodio::source::Function

§

impl Send for devela::_dep::rodio::source::SeekError

§

impl Send for devela::_dep::rustix::fs::Advice

§

impl Send for devela::_dep::rustix::fs::FileType

§

impl Send for FlockOperation

§

impl Send for devela::_dep::rustix::fs::SeekFrom

§

impl Send for IoringMsgringCmds

§

impl Send for IoringOp

§

impl Send for IoringRegisterOp

§

impl Send for IoringRestrictionOp

§

impl Send for devela::_dep::rustix::ioctl::Direction

§

impl Send for devela::_dep::rustix::mm::Advice

§

impl Send for devela::_dep::rustix::net::Shutdown

§

impl Send for SocketAddrAny

§

impl Send for Timeout

§

impl Send for DumpableBehavior

§

impl Send for EndianMode

§

impl Send for FloatingPointMode

§

impl Send for MachineCheckMemoryCorruptionKillPolicy

§

impl Send for MembarrierCommand

§

impl Send for PTracer

§

impl Send for Resource

§

impl Send for devela::_dep::rustix::process::Signal

§

impl Send for SpeculationFeature

§

impl Send for TimeStampCounterReadability

§

impl Send for TimingMethod

§

impl Send for VirtualMemoryMapAddress

§

impl Send for RebootCommand

§

impl Send for Action

§

impl Send for OptionalActions

§

impl Send for QueueSelector

§

impl Send for Capability

§

impl Send for devela::_dep::rustix::thread::ClockId

§

impl Send for CoreSchedulingScope

§

impl Send for FutexOperation

§

impl Send for LinkNameSpaceType

§

impl Send for NanosleepRelativeResult

§

impl Send for SecureComputingMode

§

impl Send for SysCallUserDispatchFastSwitch

§

impl Send for WakeOp

§

impl Send for WakeOpCmp

§

impl Send for TimerfdClockId

§

impl Send for devela::_dep::symphonia::core::audio::Layout

§

impl Send for VerificationCheck

§

impl Send for DitherType

§

impl Send for devela::_dep::symphonia::core::errors::Error

§

impl Send for SeekErrorKind

§

impl Send for SeekMode

§

impl Send for SeekTo

§

impl Send for SeekSearchResult

§

impl Send for BitOrder

§

impl Send for ColorMode

§

impl Send for Limit

§

impl Send for StandardTagKey

§

impl Send for StandardVisualKey

§

impl Send for devela::_dep::symphonia::core::meta::Value

§

impl Send for Instantiate

§

impl Send for devela::_dep::symphonia::core::sample::SampleFormat

§

impl Send for DiskKind

§

impl Send for ProcessStatus

§

impl Send for devela::_dep::sysinfo::Signal

§

impl Send for ThreadKind

§

impl Send for UpdateKind

§

impl Send for GraphemeIncomplete

§

impl Send for Endianness

§

impl Send for devela::_dep::winnow::error::ErrorKind

§

impl Send for Needed

§

impl Send for StrContext

§

impl Send for StrContextValue

§

impl Send for CompareResult

§

impl Send for Infallible

§

impl Send for DataNotEnough

§

impl Send for MismatchedBounds

§

impl Send for PartialSpace

§

impl Send for c_void

§

impl Send for FpCategory

§

impl Send for NumError

§

impl Send for devela::num::Ordering

§

impl Send for devela::num::Sign

§

impl Send for UnitBi

§

impl Send for UnitSi

§

impl Send for Month

§

impl Send for devela::phys::Weekday

§

impl Send for devela::text::AsciiChar

§

impl Send for InvalidText

§

impl Send for IntErrorKind

§

impl Send for devela::ui::LayoutError

§

impl Send for UiError

§

impl Send for devela::work::AtomicOrdering

§

impl Send for AngleDirection

§

impl Send for AngleKind

§

impl Send for AudioError

§

impl Send for BacktraceStatus

§

impl Send for ColorError

§

impl Send for CompressionMode

§

impl Send for DrawError

§

impl Send for EncodingMode

§

impl Send for devela::all::FmtAlignment

§

impl Send for FontError

§

impl Send for ImageError

§

impl Send for devela::all::IoErrorKind

§

impl Send for MediaError

§

impl Send for MidiError

§

impl Send for NotAvailable

§

impl Send for WaveletUnitRole

§

impl Send for AllocError

§

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 devela::_core::ascii::EscapeDefault

§

impl Send for BorrowError

§

impl Send for BorrowMutError

§

impl Send for CharTryFromError

§

impl Send for DecodeUtf16Error

§

impl Send for devela::_core::char::EscapeDebug

§

impl Send for devela::_core::char::EscapeDefault

§

impl Send for devela::_core::char::EscapeUnicode

§

impl Send for ParseCharError

§

impl Send for ToLowercase

§

impl Send for ToUppercase

§

impl Send for TryFromCharError

§

impl Send for FromBytesUntilNulError

§

impl Send for FromBytesWithNulError

§

impl Send for FormattingOptions

§

impl Send for SipHasher

§

impl Send for ReturnToArg

§

impl Send for UnwindActionArg

§

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 devela::_core::ptr::Alignment

§

impl Send for ParseBoolError

§

impl Send for Utf8Error

§

impl Send for devela::_core::sync::atomic::AtomicBool

§

impl Send for devela::_core::sync::atomic::AtomicI8

§

impl Send for devela::_core::sync::atomic::AtomicI16

§

impl Send for devela::_core::sync::atomic::AtomicI32

§

impl Send for devela::_core::sync::atomic::AtomicI64

§

impl Send for devela::_core::sync::atomic::AtomicIsize

§

impl Send for devela::_core::sync::atomic::AtomicU8

§

impl Send for devela::_core::sync::atomic::AtomicU16

§

impl Send for devela::_core::sync::atomic::AtomicU32

§

impl Send for devela::_core::sync::atomic::AtomicU64

§

impl Send for devela::_core::sync::atomic::AtomicUsize

§

impl Send for devela::_dep::_alloc::alloc::Global

§

impl Send for UnorderedKeyError

§

impl Send for devela::_dep::_alloc::collections::TryReserveError

§

impl Send for FromVecWithNulError

§

impl Send for IntoStringError

§

impl Send for NulError

§

impl Send for devela::_dep::_alloc::string::FromUtf8Error

§

impl Send for devela::_dep::_alloc::string::FromUtf16Error

§

impl Send for IntoChars

§

impl Send for devela::_dep::_std::alloc::System

§

impl Send for BacktraceFrame

§

impl Send for JoinPathsError

§

impl Send for DirBuilder

§

impl Send for devela::_dep::_std::fs::DirEntry

§

impl Send for devela::_dep::_std::fs::File

§

impl Send for FileTimes

§

impl Send for devela::_dep::_std::fs::FileType

§

impl Send for devela::_dep::_std::fs::Metadata

§

impl Send for OpenOptions

§

impl Send for Permissions

§

impl Send for ReadDir

§

impl Send for DefaultHasher

§

impl Send for devela::_dep::_std::io::Empty

§

impl Send for devela::_dep::_std::io::Repeat

§

impl Send for devela::_dep::_std::io::Stderr

§

impl Send for devela::_dep::_std::io::Stdin

§

impl Send for devela::_dep::_std::io::Stdout

§

impl Send for WriterPanicked

§

impl Send for IntoIncoming

§

impl Send for TcpListener

§

impl Send for TcpStream

§

impl Send for UdpSocket

§

impl Send for PidFd

§

impl Send for stat

§

impl Send for devela::_dep::_std::os::unix::net::SocketAddr

§

impl Send for SocketCred

§

impl Send for devela::_dep::_std::os::unix::net::UCred

§

impl Send for UnixDatagram

§

impl Send for UnixListener

§

impl Send for UnixStream

§

impl Send for PipeReader

§

impl Send for PipeWriter

§

impl Send for Child

§

impl Send for ChildStderr

§

impl Send for ChildStdin

§

impl Send for ChildStdout

§

impl Send for Command

§

impl Send for ExitCode

§

impl Send for ExitStatus

§

impl Send for ExitStatusError

§

impl Send for devela::_dep::_std::process::Output

§

impl Send for Stdio

§

impl Send for DefaultRandomSource

§

impl Send for RecvError

§

impl Send for devela::_dep::_std::time::SystemTimeError

§

impl Send for devela::_dep::bumpalo::collections::string::FromUtf16Error

§

impl Send for AllocErr

§

impl Send for DisableBlinking

§

impl Send for EnableBlinking

§

impl Send for Hide

§

impl Send for MoveDown

§

impl Send for MoveLeft

§

impl Send for MoveRight

§

impl Send for MoveTo

§

impl Send for MoveToColumn

§

impl Send for MoveToNextLine

§

impl Send for MoveToPreviousLine

§

impl Send for MoveToRow

§

impl Send for MoveUp

§

impl Send for RestorePosition

§

impl Send for SavePosition

§

impl Send for Show

§

impl Send for DisableBracketedPaste

§

impl Send for DisableFocusChange

§

impl Send for DisableMouseCapture

§

impl Send for EnableBracketedPaste

§

impl Send for EnableFocusChange

§

impl Send for EnableMouseCapture

§

impl Send for KeyEvent

§

impl Send for KeyEventState

§

impl Send for KeyModifiers

§

impl Send for KeyboardEnhancementFlags

§

impl Send for MouseEvent

§

impl Send for PopKeyboardEnhancementFlags

§

impl Send for PushKeyboardEnhancementFlags

§

impl Send for devela::_dep::crossterm::style::Attributes

§

impl Send for Colors

§

impl Send for ContentStyle

§

impl Send for ResetColor

§

impl Send for SetAttribute

§

impl Send for SetAttributes

§

impl Send for SetBackgroundColor

§

impl Send for SetColors

§

impl Send for SetForegroundColor

§

impl Send for SetStyle

§

impl Send for SetUnderlineColor

§

impl Send for BeginSynchronizedUpdate

§

impl Send for Clear

§

impl Send for DisableLineWrap

§

impl Send for EnableLineWrap

§

impl Send for EndSynchronizedUpdate

§

impl Send for EnterAlternateScreen

§

impl Send for LeaveAlternateScreen

§

impl Send for ScrollDown

§

impl Send for ScrollUp

§

impl Send for SetSize

§

impl Send for WindowSize

§

impl Send for devela::_dep::jiff::civil::Date

§

impl Send for DateArithmetic

§

impl Send for DateDifference

§

impl Send for DateSeries

§

impl Send for DateTime

§

impl Send for DateTimeArithmetic

§

impl Send for DateTimeDifference

§

impl Send for DateTimeRound

§

impl Send for DateTimeSeries

§

impl Send for DateTimeWith

§

impl Send for DateWith

§

impl Send for ISOWeekDate

§

impl Send for devela::_dep::jiff::civil::Time

§

impl Send for TimeArithmetic

§

impl Send for TimeDifference

§

impl Send for TimeRound

§

impl Send for TimeSeries

§

impl Send for TimeWith

§

impl Send for WeekdaysForward

§

impl Send for WeekdaysReverse

§

impl Send for devela::_dep::jiff::fmt::friendly::SpanParser

§

impl Send for devela::_dep::jiff::fmt::friendly::SpanPrinter

§

impl Send for devela::_dep::jiff::fmt::rfc2822::DateTimeParser

§

impl Send for devela::_dep::jiff::fmt::rfc2822::DateTimePrinter

§

impl Send for BrokenDownTime

§

impl Send for devela::_dep::jiff::fmt::temporal::DateTimeParser

§

impl Send for devela::_dep::jiff::fmt::temporal::DateTimePrinter

§

impl Send for PiecesNumericOffset

§

impl Send for devela::_dep::jiff::fmt::temporal::SpanParser

§

impl Send for devela::_dep::jiff::fmt::temporal::SpanPrinter

§

impl Send for devela::_dep::jiff::Error

§

impl Send for SignedDuration

§

impl Send for SignedDurationRound

§

impl Send for devela::_dep::jiff::Span

§

impl Send for Timestamp

§

impl Send for TimestampArithmetic

§

impl Send for TimestampDifference

§

impl Send for TimestampDisplayWithOffset

§

impl Send for TimestampRound

§

impl Send for TimestampSeries

§

impl Send for Zoned

§

impl Send for ZonedArithmetic

§

impl Send for ZonedRound

§

impl Send for ZonedWith

§

impl Send for AmbiguousTimestamp

§

impl Send for AmbiguousZoned

§

impl Send for Offset

§

impl Send for OffsetArithmetic

§

impl Send for TimeZone

§

impl Send for TimeZoneDatabase

§

impl Send for TimeZoneNameIter

§

impl Send for devela::_dep::js_sys::TryFromIntError

§

impl Send for CpalBackend

§

impl Send for CpalBackendSettings

§

impl Send for MockBackend

§

impl Send for MockBackendSettings

§

impl Send for Renderer

§

impl Send for ClockHandle

§

impl Send for devela::_dep::kira::clock::ClockId

§

impl Send for ClockTime

§

impl Send for CompressorBuilder

§

impl Send for CompressorHandle

§

impl Send for DelayBuilder

§

impl Send for DelayHandle

§

impl Send for DistortionBuilder

§

impl Send for DistortionHandle

§

impl Send for EqFilterBuilder

§

impl Send for EqFilterHandle

§

impl Send for FilterBuilder

§

impl Send for FilterHandle

§

impl Send for PanningControlBuilder

§

impl Send for PanningControlHandle

§

impl Send for ReverbBuilder

§

impl Send for ReverbHandle

§

impl Send for VolumeControlBuilder

§

impl Send for VolumeControlHandle

§

impl Send for ClockInfo

§

impl Send for ListenerInfo

§

impl Send for MockInfoBuilder

§

impl Send for ListenerHandle

§

impl Send for ListenerId

§

impl Send for LfoBuilder

§

impl Send for LfoHandle

§

impl Send for ModulatorId

§

impl Send for TweenerBuilder

§

impl Send for TweenerHandle

§

impl Send for StaticSoundData

§

impl Send for StaticSoundHandle

§

impl Send for StaticSoundSettings

§

impl Send for StreamingSoundSettings

§

impl Send for Region

§

impl Send for Capacities

§

impl Send for Decibels

§

impl Send for Frame

§

impl Send for devela::_dep::kira::Mix

§

impl Send for Panning

§

impl Send for PlaybackRate

§

impl Send for ResourceLimitReached

§

impl Send for Semitones

§

impl Send for Tween

§

impl Send for MainTrackBuilder

§

impl Send for MainTrackHandle

§

impl Send for NonexistentRoute

§

impl Send for SendTrackBuilder

§

impl Send for SendTrackHandle

§

impl Send for SendTrackId

§

impl Send for SpatialTrackBuilder

§

impl Send for SpatialTrackDistances

§

impl Send for SpatialTrackHandle

§

impl Send for TrackBuilder

§

impl Send for TrackHandle

§

impl Send for devela::_dep::log::ParseLevelError

§

impl Send for SetLoggerError

§

impl Send for devela::_dep::memchr::arch::all::memchr::One

§

impl Send for devela::_dep::memchr::arch::all::memchr::Three

§

impl Send for devela::_dep::memchr::arch::all::memchr::Two

§

impl Send for devela::_dep::memchr::arch::all::packedpair::Finder

§

impl Send for Pair

§

impl Send for devela::_dep::memchr::arch::all::rabinkarp::Finder

§

impl Send for devela::_dep::memchr::arch::all::rabinkarp::FinderRev

§

impl Send for devela::_dep::memchr::arch::all::shiftor::Finder

§

impl Send for devela::_dep::memchr::arch::all::twoway::Finder

§

impl Send for devela::_dep::memchr::arch::all::twoway::FinderRev

§

impl Send for devela::_dep::memchr::arch::x86_64::avx2::memchr::One

§

impl Send for devela::_dep::memchr::arch::x86_64::avx2::memchr::Three

§

impl Send for devela::_dep::memchr::arch::x86_64::avx2::memchr::Two

§

impl Send for devela::_dep::memchr::arch::x86_64::avx2::packedpair::Finder

§

impl Send for devela::_dep::memchr::arch::x86_64::sse2::memchr::One

§

impl Send for devela::_dep::memchr::arch::x86_64::sse2::memchr::Three

§

impl Send for devela::_dep::memchr::arch::x86_64::sse2::memchr::Two

§

impl Send for devela::_dep::memchr::arch::x86_64::sse2::packedpair::Finder

§

impl Send for FinderBuilder

§

impl Send for InitError

§

impl Send for MidiInput

§

impl Send for MidiInputPort

§

impl Send for MidiOutput

§

impl Send for MidiOutputConnection

§

impl Send for MidiOutputPort

§

impl Send for Conf

§

impl Send for Icon

§

impl Send for Platform

§

impl Send for Bindings

§

impl Send for BlendState

§

impl Send for BufferId

§

impl Send for BufferLayout

§

impl Send for ContextInfo

§

impl Send for ElapsedQuery

§

impl Send for Features

§

impl Send for GlContext

§

impl Send for GlslSupport

§

impl Send for KeyMods

§

impl Send for Pipeline

§

impl Send for PipelineLayout

§

impl Send for PipelineParams

§

impl Send for RenderPass

§

impl Send for ShaderId

§

impl Send for ShaderMeta

§

impl Send for StencilFaceState

§

impl Send for StencilState

§

impl Send for TextureId

§

impl Send for TextureParams

§

impl Send for Touch

§

impl Send for UniformBlockLayout

§

impl Send for UniformDesc

§

impl Send for VertexAttribute

§

impl Send for devela::_dep::nc::c_str::CStr

§

impl Send for devela::_dep::nc::c_str::CString

§

impl Send for devela::_dep::nc::path::Path

§

impl Send for __kernel_fsid_t

§

impl Send for aio_sigset_t

§

impl Send for blk_io_trace_remap_t

§

impl Send for blk_io_trace_t

§

impl Send for blk_user_trace_setup_t

§

impl Send for bpf_attr_btf_load_t

§

impl Send for bpf_attr_element_t

§

impl Send for bpf_attr_getid_t

§

impl Send for bpf_attr_info_t

§

impl Send for bpf_attr_map_create_t

§

impl Send for bpf_attr_obj_t

§

impl Send for bpf_attr_prog_attach_t

§

impl Send for bpf_attr_prog_load_t

§

impl Send for bpf_attr_prog_test_t

§

impl Send for bpf_attr_query_t

§

impl Send for bpf_attr_raw_tracepoint_t

§

impl Send for bpf_attr_task_fd_query_t

§

impl Send for bpf_btf_info_t

§

impl Send for bpf_cgroup_dev_ctx_t

§

impl Send for bpf_cgroup_storage_key_t

§

impl Send for bpf_fib_lookup_t

§

impl Send for bpf_flow_keys_ipv4_t

§

impl Send for bpf_flow_keys_ipv6_t

§

impl Send for bpf_flow_keys_t

§

impl Send for bpf_func_info_t

§

impl Send for bpf_insn_t

§

impl Send for bpf_line_info_t

§

impl Send for bpf_lpm_trie_key_t

§

impl Send for bpf_map_info_t

§

impl Send for bpf_perf_event_value_t

§

impl Send for bpf_prog_info_t

§

impl Send for bpf_raw_tracepoint_args_t

§

impl Send for bpf_sock_addr_t

§

impl Send for bpf_sock_ops_t

§

impl Send for bpf_sock_t

§

impl Send for bpf_sock_tuple_ipv4_t

§

impl Send for bpf_sock_tuple_ipv6_t

§

impl Send for bpf_spin_lock_t

§

impl Send for bpf_stack_build_id_t

§

impl Send for bpf_tcp_sock_t

§

impl Send for cachestat_range_t

§

impl Send for cachestat_t

§

impl Send for cap_user_data_t

§

impl Send for cap_user_header_t

§

impl Send for clone_args_t

§

impl Send for cmsghdr_t

§

impl Send for compat_statfs64_t

§

impl Send for cpu_set_t

§

impl Send for epoll_event_t

§

impl Send for f_owner_ex_t

§

impl Send for fd_set_t

§

impl Send for fiemap_extent_t

§

impl Send for fiemap_t

§

impl Send for file_clone_range_t

§

impl Send for file_dedupe_range_info_t

§

impl Send for file_handle_t

§

impl Send for files_stat_struct_t

§

impl Send for flock64_t

§

impl Send for flock_t

§

impl Send for fscrypt_policy_t

§

impl Send for fsid_t

§

impl Send for fstrim_range_t

§

impl Send for fsxattr_t

§

impl Send for futex_waitv_t

§

impl Send for getcpu_cache_t

§

impl Send for group_filter_t

§

impl Send for group_req_t

§

impl Send for group_source_req_t

§

impl Send for if_dqblk_t

§

impl Send for if_dqinfo_t

§

impl Send for if_nextdqblk_t

§

impl Send for in6_addr_t

§

impl Send for in6_flowlabel_req_t

§

impl Send for in_addr_t

§

impl Send for in_pktinfo_t

§

impl Send for inodes_stat_t

§

impl Send for inotify_event_t

§

impl Send for io_cqring_offsets_t

§

impl Send for io_event_t

§

impl Send for io_file_t

§

impl Send for io_sqring_offsets_t

§

impl Send for io_uring_cqe_t

§

impl Send for io_uring_files_update_t

§

impl Send for io_uring_params_t

§

impl Send for io_uring_probe_op_t

§

impl Send for io_uring_probe_t

§

impl Send for io_uring_sqe_buf_t

§

impl Send for io_uring_sqe_t

§

impl Send for iocb_t

§

impl Send for ip_mreq_source_t

§

impl Send for ip_mreq_t

§

impl Send for ip_mreqn_t

§

impl Send for ip_msfilter_t

§

impl Send for ipc64_perm_t

§

impl Send for ipc_perm_t

§

impl Send for ipv6_mreq_t

§

impl Send for itimerspec64_t

§

impl Send for itimerspec_t

§

impl Send for itimerval_t

§

impl Send for kcmp_epoll_slot_t

§

impl Send for kernel_itimerspec_t

§

impl Send for kernel_sock_timeval_t

§

impl Send for kernel_sockaddr_storage_t

§

impl Send for kernel_timespec_t

§

impl Send for kernel_timex_t

§

impl Send for kernel_timex_timeval_t

§

impl Send for kernle_old_timeval_t

§

impl Send for kexec_segment_t

§

impl Send for ktermios_t

§

impl Send for linger_t

§

impl Send for linux_dirent64_t

§

impl Send for linux_dirent_t

§

impl Send for mnt_id_req_t

§

impl Send for mount_attr_t

§

impl Send for mq_attr_t

§

impl Send for msgbuf_t

§

impl Send for msginfo_t

§

impl Send for msqid64_ds_t

§

impl Send for msqid_ds_t

§

impl Send for new_utsname_t

§

impl Send for open_how_t

§

impl Send for perf_branch_entry_t

§

impl Send for perf_event_attr_t

§

impl Send for perf_event_header_t

§

impl Send for perf_event_mmap_page_cap_detail_t

§

impl Send for perf_event_mmap_page_t

§

impl Send for perf_mem_data_mem_t

§

impl Send for pollfd_t

§

impl Send for pthread_barrierattr_t

§

impl Send for pthread_condattr_t

§

impl Send for pthread_mutexattr_t

§

impl Send for pthread_rwlockattr_t

§

impl Send for ptrace_peeksiginfo_args_t

§

impl Send for ptrace_syscall_info_seccomp_entry_t

§

impl Send for ptrace_syscall_info_seccomp_exit_t

§

impl Send for ptrace_syscall_info_seccomp_seccomp_t

§

impl Send for ptrace_syscall_info_t

§

impl Send for rlimit64_t

§

impl Send for rlimit_t

§

impl Send for rseq_cs_ptr_t

§

impl Send for rseq_cs_t

§

impl Send for rseq_t

§

impl Send for rusage_t

§

impl Send for sched_attr_t

§

impl Send for sched_param_t

§

impl Send for scm_timestamping_internal_t

§

impl Send for seccomp_data_t

§

impl Send for seccomp_metadata_t

§

impl Send for seccomp_notif_resp_t

§

impl Send for seccomp_notif_sizes_t

§

impl Send for seccomp_notif_t

§

impl Send for sembuf_t

§

impl Send for semid_ds_t

§

impl Send for seminfo_t

§

impl Send for serial_icounter_struct_t

§

impl Send for serial_iso7816_t

§

impl Send for serial_multiport_struct_t

§

impl Send for serial_rs485_t

§

impl Send for shm_info_t

§

impl Send for shmid64_ds_t

§

impl Send for shmid_ds_t

§

impl Send for shminfo64_t

§

impl Send for shminfo_t

§

impl Send for si_kill_t

§

impl Send for si_rt_t

§

impl Send for si_sigchld_t

§

impl Send for si_sigpoll_t

§

impl Send for si_sigsys_t

§

impl Send for si_timer_t

§

impl Send for sigaction_t

§

impl Send for sigaltstack_t

§

impl Send for sigev_thread_t

§

impl Send for sigevent_t

§

impl Send for siginfo_intern_t

§

impl Send for sigset_t

§

impl Send for sk_msg_md_t

§

impl Send for sk_reuseport_md_t

§

impl Send for sockaddr_in6_t

§

impl Send for sockaddr_in_t

§

impl Send for sockaddr_t

§

impl Send for stat_t

§

impl Send for statfs64_t

§

impl Send for statfs_t

§

impl Send for statmount_t

§

impl Send for statx_t

§

impl Send for statx_timestamp_t

§

impl Send for sysinfo_t

§

impl Send for termio_t

§

impl Send for termios2_t

§

impl Send for termios_t

§

impl Send for timespec64_t

§

impl Send for timespec_t

§

impl Send for timeval_t

§

impl Send for timex_t

§

impl Send for timezone_t

§

impl Send for tms_t

§

impl Send for ucred_t

§

impl Send for user_desc_t

§

impl Send for ustat_t

§

impl Send for utimbuf_t

§

impl Send for winsize_t

§

impl Send for xdp_md_t

§

impl Send for devela::_dep::nc::util::File

§

impl Send for PyAsyncMethods

§

impl Send for PyBufferProcs

§

impl Send for PyCompilerFlags

§

impl Send for PyDictKeysObject

§

impl Send for PyFutureFeatures

§

impl Send for PyInterpreterState

§

impl Send for PyLongObject

§

impl Send for PyMappingMethods

§

impl Send for PyPreConfig

§

impl Send for PyThreadState

§

impl Send for PyTryBlock

§

impl Send for Py_complex

§

impl Send for _PyOpcache

§

impl Send for PyBorrowError

§

impl Send for PyBorrowMutError

§

impl Send for PyErr

§

impl Send for PyTraverseError

§

impl Send for PySliceIndices

§

impl Send for devela::_dep::rand_core::Error

§

impl Send for OsRng

§

impl Send for ApmInfo

§

impl Send for CacheInfo

§

impl Send for CacheInfoIter

§

impl Send for CacheParameter

§

impl Send for CpuIdReaderNative

§

impl Send for CpuIdResult

§

impl Send for DatInfo

§

impl Send for DirectCacheAccessInfo

§

impl Send for EpcSection

§

impl Send for ExtendedFeatures

§

impl Send for ExtendedProcessorFeatureIdentifiers

§

impl Send for ExtendedState

§

impl Send for ExtendedTopologyLevel

§

impl Send for FeatureInfo

§

impl Send for L1CacheTlbInfo

§

impl Send for L2And3CacheTlbInfo

§

impl Send for L2CatInfo

§

impl Send for L3CatInfo

§

impl Send for L3MonitoringInfo

§

impl Send for MemBwAllocationInfo

§

impl Send for MemoryEncryptionInfo

§

impl Send for MonitorMwaitInfo

§

impl Send for PerformanceMonitoringInfo

§

impl Send for PerformanceOptimizationInfo

§

impl Send for ProcessorBrandString

§

impl Send for ProcessorCapacityAndFeatureInfo

§

impl Send for ProcessorFrequencyInfo

§

impl Send for ProcessorSerial

§

impl Send for ProcessorTopologyInfo

§

impl Send for ProcessorTraceInfo

§

impl Send for SoCVendorBrand

§

impl Send for SvmFeatures

§

impl Send for ThermalPowerInfo

§

impl Send for Tlb1gbPageInfo

§

impl Send for TscInfo

§

impl Send for VendorInfo

§

impl Send for ThreadBuilder

§

impl Send for ThreadPool

§

impl Send for ThreadPoolBuildError

§

impl Send for CaptureLocations

§

impl Send for devela::_dep::regex_lite::Error

§

impl Send for Regex

§

impl Send for RegexBuilder

§

impl Send for BoxResolver

§

impl Send for BoxedError

§

impl Send for devela::_dep::rkyv::bytecheck::rancor::Error

§

impl Send for Failure

§

impl Send for NamedEnumVariantCheckContext

§

impl Send for StructCheckContext

§

impl Send for TupleStructCheckContext

§

impl Send for UnnamedEnumVariantCheckContext

§

impl Send for BTreeMapResolver

§

impl Send for BTreeSetResolver

§

impl Send for HashMapResolver

§

impl Send for HashSetResolver

§

impl Send for HashTableResolver

§

impl Send for IndexMapResolver

§

impl Send for IndexSetResolver

§

impl Send for IteratorLengthMismatch

§

impl Send for Unpool

§

impl Send for ArchivedCString

§

impl Send for CStringResolver

§

impl Send for FxHasher64

§

impl Send for Borrow

§

impl Send for Move

§

impl Send for ArchivedIpv4Addr

§

impl Send for ArchivedIpv6Addr

§

impl Send for ArchivedSocketAddrV4

§

impl Send for ArchivedSocketAddrV6

§

impl Send for Bool

§

impl Send for NaN

§

impl Send for Null

§

impl Send for devela::_dep::rkyv::niche::niching::Zero

§

impl Send for ArchivedOptionNonZeroI8

§

impl Send for ArchivedOptionNonZeroI16

§

impl Send for ArchivedOptionNonZeroI32

§

impl Send for ArchivedOptionNonZeroI64

§

impl Send for ArchivedOptionNonZeroI128

§

impl Send for ArchivedOptionNonZeroU8

§

impl Send for ArchivedOptionNonZeroU16

§

impl Send for ArchivedOptionNonZeroU32

§

impl Send for ArchivedOptionNonZeroU64

§

impl Send for ArchivedOptionNonZeroU128

§

impl Send for ArchivedRangeFull

§

impl Send for ArcFlavor

§

impl Send for RcFlavor

§

impl Send for RcResolver

§

impl Send for RcWeakResolver

§

impl Send for AtomicI16_be

§

impl Send for AtomicI16_le

§

impl Send for AtomicI32_be

§

impl Send for AtomicI32_le

§

impl Send for AtomicI64_be

§

impl Send for AtomicI64_le

§

impl Send for AtomicU16_be

§

impl Send for AtomicU16_le

§

impl Send for AtomicU32_be

§

impl Send for AtomicU32_le

§

impl Send for AtomicU64_be

§

impl Send for AtomicU64_le

§

impl Send for NonZeroI16_be

§

impl Send for NonZeroI16_le

§

impl Send for NonZeroI32_be

§

impl Send for NonZeroI32_le

§

impl Send for NonZeroI64_be

§

impl Send for NonZeroI64_le

§

impl Send for NonZeroI128_be

§

impl Send for NonZeroI128_le

§

impl Send for NonZeroU16_be

§

impl Send for NonZeroU16_le

§

impl Send for NonZeroU32_be

§

impl Send for NonZeroU32_le

§

impl Send for NonZeroU64_be

§

impl Send for NonZeroU64_le

§

impl Send for NonZeroU128_be

§

impl Send for NonZeroU128_le

§

impl Send for char_be

§

impl Send for char_le

§

impl Send for f32_be

§

impl Send for f32_le

§

impl Send for f64_be

§

impl Send for f64_le

§

impl Send for i16_be

§

impl Send for i16_le

§

impl Send for i32_be

§

impl Send for i32_le

§

impl Send for i64_be

§

impl Send for i64_le

§

impl Send for i128_be

§

impl Send for i128_le

§

impl Send for u16_be

§

impl Send for u16_le

§

impl Send for u32_be

§

impl Send for u32_le

§

impl Send for u64_be

§

impl Send for u64_le

§

impl Send for u128_be

§

impl Send for u128_le

§

impl Send for NonZeroI16_ube

§

impl Send for NonZeroI16_ule

§

impl Send for NonZeroI32_ube

§

impl Send for NonZeroI32_ule

§

impl Send for NonZeroI64_ube

§

impl Send for NonZeroI64_ule

§

impl Send for NonZeroI128_ube

§

impl Send for NonZeroI128_ule

§

impl Send for NonZeroU16_ube

§

impl Send for NonZeroU16_ule

§

impl Send for NonZeroU32_ube

§

impl Send for NonZeroU32_ule

§

impl Send for NonZeroU64_ube

§

impl Send for NonZeroU64_ule

§

impl Send for NonZeroU128_ube

§

impl Send for NonZeroU128_ule

§

impl Send for char_ube

§

impl Send for char_ule

§

impl Send for f32_ube

§

impl Send for f32_ule

§

impl Send for f64_ube

§

impl Send for f64_ule

§

impl Send for i16_ube

§

impl Send for i16_ule

§

impl Send for i32_ube

§

impl Send for i32_ule

§

impl Send for i64_ube

§

impl Send for i64_ule

§

impl Send for i128_ube

§

impl Send for i128_ule

§

impl Send for u16_ube

§

impl Send for u16_ule

§

impl Send for u32_ube

§

impl Send for u32_ule

§

impl Send for u64_ube

§

impl Send for u64_ule

§

impl Send for u128_ube

§

impl Send for u128_ule

§

impl Send for AllocationStats

§

impl Send for Share

§

impl Send for devela::_dep::rkyv::ser::sharing::Unshare

§

impl Send for ArchivedString

§

impl Send for StringResolver

§

impl Send for ArchivedDuration

§

impl Send for SharedValidator

§

impl Send for VecResolver

§

impl Send for Acquire

§

impl Send for AsBox

§

impl Send for AsOwned

§

impl Send for AsString

§

impl Send for AsUnixTime

§

impl Send for AsVec

§

impl Send for DefaultNiche

§

impl Send for devela::_dep::rkyv::with::Identity

§

impl Send for Inline

§

impl Send for InlineAsBox

§

impl Send for Lock

§

impl Send for Niche

§

impl Send for Relaxed

§

impl Send for SeqCst

§

impl Send for devela::_dep::rkyv::with::Skip

§

impl Send for Unsafe

§

impl Send for devela::_dep::rkyv::with::Unshare

§

impl Send for devela::_dep::rodio::cpal::platform::AlsaDevice

§

impl Send for devela::_dep::rodio::cpal::platform::AlsaHost

§

impl Send for devela::_dep::rodio::cpal::platform::AlsaStream

§

impl Send for BackendSpecificError

§

impl Send for devela::_dep::rodio::cpal::Host

§

impl Send for HostUnavailable

§

impl Send for I24

§

impl Send for I48

§

impl Send for InputCallbackInfo

§

impl Send for InputStreamTimestamp

§

impl Send for OutputCallbackInfo

§

impl Send for OutputStreamTimestamp

§

impl Send for SampleRate

§

impl Send for StreamConfig

§

impl Send for StreamInstant

§

impl Send for SupportedInputConfigs

§

impl Send for SupportedOutputConfigs

§

impl Send for SupportedStreamConfigRange

§

impl Send for U24

§

impl Send for U48

§

impl Send for Chirp

§

impl Send for SignalGenerator

§

impl Send for SineWave

§

impl Send for devela::_dep::rodio::Device

§

impl Send for devela::_dep::rodio::Devices

§

impl Send for OutputStreamHandle

§

impl Send for devela::_dep::rodio::Sink

§

impl Send for SpatialSink

§

impl Send for SupportedStreamConfig

§

impl Send for devela::_dep::rustix::event::epoll::CreateFlags

§

impl Send for EventfdFlags

§

impl Send for FdSetElement

§

impl Send for PollFlags

§

impl Send for OwnedFd

§

impl Send for devela::_dep::rustix::fs::inotify::CreateFlags

§

impl Send for ReadFlags

§

impl Send for WatchFlags

§

impl Send for Access

§

impl Send for AtFlags

§

impl Send for Dir

§

impl Send for devela::_dep::rustix::fs::DirEntry

§

impl Send for FallocateFlags

§

impl Send for FdFlags

§

impl Send for devela::_dep::rustix::fs::Gid

§

impl Send for IFlags

§

impl Send for MemfdFlags

§

impl Send for Mode

§

impl Send for MountFlags

§

impl Send for MountPropagationFlags

§

impl Send for OFlags

§

impl Send for RenameFlags

§

impl Send for ResolveFlags

§

impl Send for SealFlags

§

impl Send for StatVfs

§

impl Send for StatVfsMountFlags

§

impl Send for StatxFlags

§

impl Send for Timestamps

§

impl Send for devela::_dep::rustix::fs::Uid

§

impl Send for UnmountFlags

§

impl Send for XattrFlags

§

impl Send for DupFlags

§

impl Send for Errno

§

impl Send for ReadWriteFlags

§

impl Send for EventFlags

§

impl Send for IoringAcceptFlags

§

impl Send for IoringAsyncCancelFlags

§

impl Send for IoringCqFlags

§

impl Send for IoringCqeFlags

§

impl Send for IoringEnterFlags

§

impl Send for IoringFeatureFlags

§

impl Send for IoringFsyncFlags

§

impl Send for IoringMsgringFlags

§

impl Send for IoringOpFlags

§

impl Send for IoringPollFlags

§

impl Send for IoringRecvFlags

§

impl Send for IoringRegisterFlags

§

impl Send for IoringRsrcFlags

§

impl Send for IoringSendFlags

§

impl Send for IoringSetupFlags

§

impl Send for IoringSqFlags

§

impl Send for IoringSqeFlags

§

impl Send for IoringTimeoutFlags

§

impl Send for RecvFlags

§

impl Send for RecvmsgOutFlags

§

impl Send for SendFlags

§

impl Send for SocketFlags

§

impl Send for devela::_dep::rustix::io_uring::SpliceFlags

§

impl Send for addr3_struct

§

impl Send for addr_len_struct

§

impl Send for buf_ring_bufs_struct

§

impl Send for buf_ring_tail_struct

§

impl Send for cmd_op_struct

§

impl Send for io_cqring_offsets

§

impl Send for io_sqring_offsets

§

impl Send for io_uring_buf

§

impl Send for io_uring_buf_reg

§

impl Send for io_uring_buf_ring

§

impl Send for io_uring_files_update

§

impl Send for io_uring_getevents_arg

§

impl Send for io_uring_params

§

impl Send for io_uring_probe

§

impl Send for io_uring_probe_op

§

impl Send for io_uring_recvmsg_out

§

impl Send for io_uring_restriction

§

impl Send for io_uring_rsrc_register

§

impl Send for io_uring_rsrc_update2

§

impl Send for io_uring_rsrc_update

§

impl Send for io_uring_sync_cancel_reg

§

impl Send for open_how

§

impl Send for tail_or_bufs_struct

§

impl Send for Opcode

§

impl Send for MapFlags

§

impl Send for MlockAllFlags

§

impl Send for MlockFlags

§

impl Send for MprotectFlags

§

impl Send for MremapFlags

§

impl Send for MsyncFlags

§

impl Send for ProtFlags

§

impl Send for UserfaultfdFlags

§

impl Send for FsMountFlags

§

impl Send for FsOpenFlags

§

impl Send for FsPickFlags

§

impl Send for MountAttrFlags

§

impl Send for MoveMountFlags

§

impl Send for OpenTreeFlags

§

impl Send for AddressFamily

§

impl Send for Protocol

§

impl Send for RecvMsgReturn

§

impl Send for SocketAddrUnix

§

impl Send for SocketType

§

impl Send for devela::_dep::rustix::net::UCred

§

impl Send for SockaddrXdpFlags

§

impl Send for SocketAddrXdp

§

impl Send for XdpDesc

§

impl Send for XdpDescOptions

§

impl Send for XdpMmapOffsets

§

impl Send for XdpOptions

§

impl Send for XdpOptionsFlags

§

impl Send for XdpRingFlags

§

impl Send for XdpRingOffset

§

impl Send for XdpStatistics

§

impl Send for XdpUmemReg

§

impl Send for XdpUmemRegFlags

§

impl Send for DecInt

§

impl Send for PipeFlags

§

impl Send for devela::_dep::rustix::pipe::SpliceFlags

§

impl Send for CpuSet

§

impl Send for Cpuid

§

impl Send for FloatingPointEmulationControl

§

impl Send for FloatingPointExceptionMode

§

impl Send for MembarrierQuery

§

impl Send for devela::_dep::rustix::process::Pid

§

impl Send for PidfdFlags

§

impl Send for PidfdGetfdFlags

§

impl Send for Rlimit

§

impl Send for SpeculationFeatureControl

§

impl Send for SpeculationFeatureState

§

impl Send for UnalignedAccessControl

§

impl Send for WaitOptions

§

impl Send for WaitStatus

§

impl Send for WaitidOptions

§

impl Send for OpenptFlags

§

impl Send for GetRandomFlags

§

impl Send for ShmOFlags

§

impl Send for Uname

§

impl Send for ControlModes

§

impl Send for InputModes

§

impl Send for LocalModes

§

impl Send for OutputModes

§

impl Send for SpecialCodeIndex

§

impl Send for SpecialCodes

§

impl Send for Termios

§

impl Send for CapabilitiesSecureBits

§

impl Send for CapabilityFlags

§

impl Send for CapabilitySets

§

impl Send for Flags

§

impl Send for SVEVectorLengthConfig

§

impl Send for TaggedAddressMode

§

impl Send for ThreadNameSpaceType

§

impl Send for UnshareFlags

§

impl Send for TimerfdFlags

§

impl Send for TimerfdTimerFlags

§

impl Send for IgnoredAny

§

impl Send for devela::_dep::serde::de::value::Error

§

impl Send for Channels

§

impl Send for ChannelsIter

§

impl Send for SignalSpec

§

impl Send for Crc8Ccitt

§

impl Send for Crc16Ansi

§

impl Send for Crc16AnsiLe

§

impl Send for Crc32

§

impl Send for Md5

§

impl Send for CodecDescriptor

§

impl Send for CodecParameters

§

impl Send for CodecRegistry

§

impl Send for CodecType

§

impl Send for DecoderOptions

§

impl Send for FinalizeResult

§

impl Send for RandomNoise

§

impl Send for Complex

§

impl Send for Fft

§

impl Send for Imdct

§

impl Send for Cue

§

impl Send for CuePoint

§

impl Send for FormatOptions

§

impl Send for Packet

§

impl Send for SeekedTo

§

impl Send for Track

§

impl Send for SeekIndex

§

impl Send for SeekPoint

§

impl Send for MediaSourceStream

§

impl Send for MediaSourceStreamOptions

§

impl Send for CodebookBuilder

§

impl Send for Entry8x8

§

impl Send for Entry8x16

§

impl Send for Entry8x32

§

impl Send for Entry16x8

§

impl Send for Entry16x16

§

impl Send for Entry16x32

§

impl Send for Entry32x8

§

impl Send for Entry32x16

§

impl Send for Entry32x32

§

impl Send for devela::_dep::symphonia::core::meta::MetadataBuilder

§

impl Send for MetadataLog

§

impl Send for MetadataOptions

§

impl Send for MetadataRevision

§

impl Send for Size

§

impl Send for devela::_dep::symphonia::core::meta::Tag

§

impl Send for VendorData

§

impl Send for Visual

§

impl Send for Descriptor

§

impl Send for Hint

§

impl Send for Probe

§

impl Send for ProbeResult

§

impl Send for ProbedMetadata

§

impl Send for i24

§

impl Send for u24

§

impl Send for devela::_dep::symphonia::core::units::Time

§

impl Send for TimeBase

§

impl Send for CGroupLimits

§

impl Send for devela::_dep::sysinfo::Component

§

impl Send for devela::_dep::sysinfo::Components

§

impl Send for Cpu

§

impl Send for CpuRefreshKind

§

impl Send for Disk

§

impl Send for DiskRefreshKind

§

impl Send for DiskUsage

§

impl Send for Disks

§

impl Send for devela::_dep::sysinfo::Gid

§

impl Send for Group

§

impl Send for Groups

§

impl Send for IpNetwork

§

impl Send for LoadAvg

§

impl Send for MacAddr

§

impl Send for MemoryRefreshKind

§

impl Send for NetworkData

§

impl Send for Networks

§

impl Send for devela::_dep::sysinfo::Pid

§

impl Send for Process

§

impl Send for ProcessRefreshKind

§

impl Send for RefreshKind

§

impl Send for devela::_dep::sysinfo::System

§

impl Send for devela::_dep::sysinfo::Uid

§

impl Send for User

§

impl Send for Users

§

impl Send for OutputDevice

§

impl Send for OutputDeviceParameters

§

impl Send for DuplexStream

§

impl Send for devela::_dep::tokio::io::Empty

§

impl Send for devela::_dep::tokio::io::Repeat

§

impl Send for SimplexStream

§

impl Send for devela::_dep::tokio::io::Sink

§

impl Send for devela::_dep::tokio::io::Stderr

§

impl Send for devela::_dep::tokio::io::Stdin

§

impl Send for devela::_dep::tokio::io::Stdout

§

impl Send for DefaultCallsite

§

impl Send for Identifier

§

impl Send for DefaultGuard

§

impl Send for SetGlobalDefaultError

§

impl Send for WeakDispatch

§

impl Send for devela::_dep::tracing::field::Empty

§

impl Send for Field

§

impl Send for FieldSet

§

impl Send for devela::_dep::tracing::field::Iter

§

impl Send for devela::_dep::tracing::level_filters::LevelFilter

§

impl Send for ParseLevelFilterError

§

impl Send for Kind

§

impl Send for devela::_dep::tracing::metadata::ParseLevelError

§

impl Send for Dispatch

§

impl Send for Id

§

impl Send for devela::_dep::tracing::Level

§

impl Send for devela::_dep::tracing::Span

§

impl Send for Interest

§

impl Send for NoSubscriber

§

impl Send for GraphemeCursor

§

impl Send for WasmSlice

§

impl Send for f32x4

§

impl Send for f32x8

§

impl Send for f64x2

§

impl Send for f64x4

§

impl Send for i8x16

§

impl Send for i8x32

§

impl Send for i16x8

§

impl Send for i16x16

§

impl Send for i32x4

§

impl Send for i32x8

§

impl Send for i64x2

§

impl Send for i64x4

§

impl Send for u8x16

§

impl Send for u16x8

§

impl Send for u16x16

§

impl Send for u32x4

§

impl Send for u32x8

§

impl Send for u64x2

§

impl Send for u64x4

§

impl Send for devela::_dep::winnow::stream::Range

§

impl Send for BStr

§

impl Send for devela::_dep::winnow::Bytes

§

impl Send for ExampleBitfield

§

impl Send for ExampleBitfieldCustom

§

impl Send for ExampleBitfieldExtra

§

impl Send for ExampleEnumSet

§

impl Send for ExampleIdSeqUsize

§

impl Send for TypeId

§

impl Send for DataOverflow

§

impl Send for ElementNotFound

§

impl Send for IdPinBox

§

impl Send for IndexOutOfBounds

§

impl Send for InvalidAxisLength

§

impl Send for KeyAlreadyExists

§

impl Send for MismatchedCapacity

§

impl Send for MismatchedDimensions

§

impl Send for MismatchedIndices

§

impl Send for NodeEmpty

§

impl Send for NodeLinkNotSet

§

impl Send for NodeLinkNotUnique

§

impl Send for NotEnoughElements

§

impl Send for NotEnoughSpace

§

impl Send for PartiallyAdded

§

impl Send for devela::lang::CStr

§

impl Send for devela::lang::CString

§

impl Send for OsStr

§

impl Send for OsString

§

impl Send for Duration

§

impl Send for TryFromFloatSecsError

§

impl Send for Instant

§

impl Send for SystemTime

§

impl Send for devela::phys::SystemTimeError

§

impl Send for Timecode

§

impl Send for UnixTimeI64

§

impl Send for UnixTimeU32

§

impl Send for Env

§

impl Send for ByteSearch

§

impl Send for Char

§

impl Send for GraphemeString

§

impl Send for InvalidChar

§

impl Send for InvalidUtf8

§

impl Send for ParseFloatError

§

impl Send for ParseIntError

§

impl Send for char7

§

impl Send for char8

§

impl Send for char16

§

impl Send for devela::work::AtomicBool

§

impl Send for AtomicF32

§

impl Send for AtomicF64

§

impl Send for devela::work::AtomicI8

§

impl Send for devela::work::AtomicI16

§

impl Send for devela::work::AtomicI32

§

impl Send for devela::work::AtomicI64

§

impl Send for AtomicI128

§

impl Send for devela::work::AtomicIsize

§

impl Send for devela::work::AtomicU8

§

impl Send for devela::work::AtomicU16

§

impl Send for devela::work::AtomicU32

§

impl Send for devela::work::AtomicU64

§

impl Send for AtomicU128

§

impl Send for devela::work::AtomicUsize

§

impl Send for Barrier

§

impl Send for BarrierWaitResult

§

impl Send for Condvar

§

impl Send for devela::work::Once

§

impl Send for OnceState

§

impl Send for RawWakerVTable

§

impl Send for Thread

§

impl Send for AccessError

§

impl Send for Builder

§

impl Send for ThreadId

§

impl Send for WaitTimeoutResult

§

impl Send for Alloc

§

impl Send for Arch

§

impl Send for ArchivedBoxed

§

impl Send for Backtrace

§

impl Send for Boxed

§

impl Send for BoxedResolver

§

impl Send for devela::all::Color

§

impl Send for FailedErrorConversion

§

impl Send for devela::all::False

§

impl Send for devela::all::FmtError

§

impl Send for HasherPengy

§

impl Send for devela::all::IoError

§

impl Send for devela::all::IoSink

§

impl Send for LINUX_ERRNO

§

impl Send for LINUX_FILENO

§

impl Send for LINUX_IOCTL

§

impl Send for LINUX_SIGACTION

§

impl Send for LINUX_SIGNAL

§

impl Send for LINUX_SYS_AARCH64

§

impl Send for LINUX_SYS_ARM

§

impl Send for LINUX_SYS_RISCV

§

impl Send for LINUX_SYS_X86

§

impl Send for LINUX_SYS_X86_64

§

impl Send for LINUX_TERMIOS_CFLAG

§

impl Send for LINUX_TERMIOS_IFLAG

§

impl Send for LINUX_TERMIOS_LFLAG

§

impl Send for LINUX_TERMIOS_OFLAG

§

impl Send for devela::all::Layout

§

impl Send for devela::all::LayoutError

§

impl Send for Lgc16

§

impl Send for LinuxSigaction

§

impl Send for LinuxSigset

§

impl Send for LinuxTerminal

§

impl Send for LinuxTerminalSize

§

impl Send for LinuxTermios

§

impl Send for LinuxTimespec

§

impl Send for Mem

§

impl Send for NotImplemented

§

impl Send for NotSupported

§

impl Send for devela::all::Path

§

impl Send for PathBuf

§

impl Send for StripPrefixError

§

impl Send for PhantomPinned

§

impl Send for Pnm

§

impl Send for Ptr

§

impl Send for RandomState

§

impl Send for RangeFull

§

impl Send for Str

§

impl Send for devela::all::String

§

impl Send for devela::all::True

§

impl Send for devela::all::TryFromIntError

§

impl Send for WaveletHaar

§

impl Send for WaveletUnitVec

§

impl Send for Xabc

§

impl Send for XorShift8

§

impl Send for XorShift16

§

impl Send for XorShift32

§

impl Send for XorShift64

§

impl Send for XorShift128

§

impl Send for XorShift128p

§

impl Send for Xoroshiro128pp

§

impl Send for Xyza8a

§

impl Send for Xyza8b

§

impl Send for m128

§

impl Send for m128d

§

impl Send for m128i

§

impl Send for m256

§

impl Send for m256d

§

impl Send for m256i

§

impl Send for bpf_attr_getid_id_t

§

impl Send for bpf_attr_t

§

impl Send for bpf_fib_lookup_addr_t

§

impl Send for bpf_fib_lookup_inputs_t

§

impl Send for bpf_flow_keys_addr_t

§

impl Send for bpf_md_end_ptr_t

§

impl Send for bpf_md_ptr_t

§

impl Send for bpf_sock_ops_reply_t

§

impl Send for bpf_sock_tuple_t

§

impl Send for epoll_data_t

§

impl Send for in6_un_t

§

impl Send for io_uring_sqe_buf_addr_t

§

impl Send for io_uring_sqe_buf_group_t

§

impl Send for io_uring_sqe_file_off_t

§

impl Send for io_uring_sqe_opt_buf_t

§

impl Send for io_uring_sqe_other_flags_t

§

impl Send for perf_event_attr_config1_t

§

impl Send for perf_event_attr_config2_t

§

impl Send for perf_event_attr_sample_t

§

impl Send for perf_event_attr_wakeup_t

§

impl Send for perf_event_mmap_page_cap_t

§

impl Send for perf_mem_data_src_t

§

impl Send for ptrace_syscall_info_seccomp_t

§

impl Send for rseq_cs_union_t

§

impl Send for sifields_t

§

impl Send for sigev_un_t

§

impl Send for siginfo_t

§

impl Send for sigval_t

§

impl Send for devela::_dep::rkyv::de::Metadata

§

impl Send for ArchivedStringRepr

§

impl Send for addr3_or_cmd_union

§

impl Send for buf_union

§

impl Send for ioprio_union

§

impl Send for len_union

§

impl Send for op_flags_union

§

impl Send for register_or_sqe_op_or_sqe_flags_union

§

impl Send for splice_fd_in_or_file_index_union

§

impl Send for AdjacentlyTaggedEnumVariant

§

impl Send for AsciiCase

§

impl Send for AsyncIterBaseTag

§

impl Send for AsyncIterOptionTag

§

impl Send for AsyncIterResultOptionTag

§

impl Send for Big8x3

§

impl Send for Big32x40

§

impl Send for Decoded

§

impl Send for Deprecation

§

impl Send for DictVarkeywords

§

impl Send for False

§

impl Send for FmtSpec

§

impl Send for Fork

§

impl Send for FullDecoded

§

impl Send for FunctionDescription

§

impl Send for HashCallbackOutput

§

impl Send for How

§

impl Send for I32NotAllOnes

§

impl Send for I64NotAllOnes

§

impl Send for ImportedExceptionTypeObject

§

impl Send for IterBaseTag

§

impl Send for IterOptionTag

§

impl Send for IterResultOptionTag

§

impl Send for KeywordOnlyParameterDescription

§

impl Send for ModuleInitializer

§

impl Send for MustAbort

§

impl Send for Nanoseconds

§

impl Send for NoVarargs

§

impl Send for NoVarkeywords

§

impl Send for NonZeroI8Inner

§

impl Send for NonZeroI16Inner

§

impl Send for NonZeroI32Inner

§

impl Send for NonZeroI64Inner

§

impl Send for NonZeroI128Inner

§

impl Send for NonZeroIsizeInner

§

impl Send for NonZeroU8Inner

§

impl Send for NonZeroU16Inner

§

impl Send for NonZeroU32Inner

§

impl Send for NonZeroU64Inner

§

impl Send for NonZeroU128Inner

§

impl Send for NonZeroUsizeInner

§

impl Send for Number

§

impl Send for PanicTrap

§

impl Send for PyClassAttributeDef

§

impl Send for PyClassDummySlot

§

impl Send for PyClassItemsIter

§

impl Send for PyGetterDef

§

impl Send for PyMethodDef

§

impl Send for PyMethodType

§

impl Send for PySetterDef

§

impl Send for Sign

§

impl Send for TagContentOtherField

§

impl Send for TagContentOtherFieldVisitor

§

impl Send for TagOrContentField

§

impl Send for TagOrContentFieldVisitor

§

impl Send for True

§

impl Send for TryCaptureWithDebug

§

impl Send for TryCaptureWithoutDebug

§

impl Send for TupleVarargs

§

impl Send for U32NotAllOnes

§

impl Send for U64NotAllOnes

§

impl Send for UsizeNoHighBit

§

impl Send for Utf8Encoder

§

impl Send for Utf16Encoder

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<'a> !Send for devela::_dep::js_sys::Iter<'a>

§

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

§

impl<'a> !Send for devela::_dep::log::Record<'a>

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<'a> !Send for devela::_dep::rustix::event::epoll::Iter<'a>

§

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

§

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

§

impl<'a> !Send for devela::_dep::tracing::span::Attributes<'a>

§

impl<'a> !Send for devela::_dep::tracing::span::Record<'a>

§

impl<'a> !Send for devela::_dep::tracing::Event<'a>

§

impl<'a> !Send for devela::work::TaskContext<'a>

§

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

§

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

§

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

§

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

§

impl<'a> Send for ShaderSource<'a>

§

impl<'a> Send for TextureSource<'a>

§

impl<'a> Send for PyStringData<'a>

§

impl<'a> Send for RecvAncillaryMessage<'a>

§

impl<'a> Send for WaitId<'a>

§

impl<'a> Send for DynamicClockId<'a>

§

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

§

impl<'a> Send for MatcherType<'a>

§

impl<'a> Send for AudioBufferRef<'a>

§

impl<'a> Send for ProcessesToUpdate<'a>

§

impl<'a> Send for devela::all::PathComponent<'a>

§

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

§

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

§

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

§

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

§

impl<'a> Send for devela::_core::str::Bytes<'a>

§

impl<'a> Send for devela::_core::str::CharIndices<'a>

§

impl<'a> Send for devela::_core::str::EncodeUtf16<'a>

§

impl<'a> Send for devela::_core::str::EscapeDebug<'a>

§

impl<'a> Send for devela::_core::str::EscapeDefault<'a>

§

impl<'a> Send for devela::_core::str::EscapeUnicode<'a>

§

impl<'a> Send for devela::_core::str::Lines<'a>

§

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

§

impl<'a> Send for devela::_core::str::SplitAsciiWhitespace<'a>

§

impl<'a> Send for devela::_core::str::SplitWhitespace<'a>

§

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

§

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

§

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

§

impl<'a> Send for devela::_dep::_std::ffi::os_str::Display<'a>

§

impl<'a> Send for devela::_dep::_std::net::Incoming<'a>

§

impl<'a> Send for devela::_dep::_std::os::unix::net::Incoming<'a>

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<'a> Send for devela::_dep::log::Metadata<'a>

§

impl<'a> Send for devela::_dep::log::MetadataBuilder<'a>

§

impl<'a> Send for kernel_clone_args_t<'a>

§

impl<'a> Send for PythonVersionInfo<'a>

§

impl<'a> Send for devela::_dep::rayon::string::Drain<'a>

§

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

§

impl<'a> Send for FdSetIter<'a>

§

impl<'a> Send for InotifyEvent<'a>

§

impl<'a> Send for RawDirEntry<'a>

§

impl<'a> Send for RangeMatches<'a>

§

impl<'a> Send for RangeRMatches<'a>

§

impl<'a> Send for RangeRSplits<'a>

§

impl<'a> Send for RangeSplits<'a>

§

impl<'a> Send for BitReaderLtr<'a>

§

impl<'a> Send for BitReaderRtl<'a>

§

impl<'a> Send for devela::_dep::symphonia::core::io::BufReader<'a>

§

impl<'a> Send for devela::_dep::symphonia::core::meta::Metadata<'a>

§

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

§

impl<'a> Send for Entered<'a>

§

impl<'a> Send for devela::_dep::tracing::Metadata<'a>

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<'a> Send for IdPin<'a>

§

impl<'a> Send for devela::text::IterChars<'a>

§

impl<'a> Send for devela::all::IterPath<'a>

§

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

§

impl<'a> Send for devela::all::IterPathComponents<'a>

§

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

§

impl<'a> Send for devela::all::PathDisplay<'a>

§

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

§

impl<'a> Send for Concat<'a>

§

impl<'a> Send for ConcatBytes<'a>

§

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

§

impl<'a> Send for InternallyTaggedUnitVisitor<'a>

§

impl<'a> Send for Join<'a>

§

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

§

impl<'a> Send for UntaggedUnitVisitor<'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, K, Q, V, S, A> Send for EntryRef<'a, 'b, K, Q, V, S, A>
where K: Send, V: Send, S: Send, A: Send, Q: Sync + ?Sized,

§

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

§

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

§

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

§

impl<'a, 'bump, I> Send for devela::_dep::bumpalo::collections::vec::Splice<'a, 'bump, I>
where I: Send, <I as Iterator>::Item: Send,

§

impl<'a, 'bump, T, F> !Send for DrainFilter<'a, 'bump, T, F>

§

impl<'a, 'de, E> Send for ContentRefDeserializer<'a, 'de, E>
where E: Send,

§

impl<'a, 'de, E> Send for FlatMapDeserializer<'a, 'de, E>
where E: Send,

§

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

§

impl<'a, 'h> Send for devela::_dep::memchr::arch::all::memchr::OneIter<'a, 'h>

§

impl<'a, 'h> Send for devela::_dep::memchr::arch::all::memchr::ThreeIter<'a, 'h>

§

impl<'a, 'h> Send for devela::_dep::memchr::arch::all::memchr::TwoIter<'a, 'h>

§

impl<'a, 'h> Send for devela::_dep::memchr::arch::x86_64::avx2::memchr::OneIter<'a, 'h>

§

impl<'a, 'h> Send for devela::_dep::memchr::arch::x86_64::avx2::memchr::ThreeIter<'a, 'h>

§

impl<'a, 'h> Send for devela::_dep::memchr::arch::x86_64::avx2::memchr::TwoIter<'a, 'h>

§

impl<'a, 'h> Send for devela::_dep::memchr::arch::x86_64::sse2::memchr::OneIter<'a, 'h>

§

impl<'a, 'h> Send for devela::_dep::memchr::arch::x86_64::sse2::memchr::ThreeIter<'a, 'h>

§

impl<'a, 'h> Send for devela::_dep::memchr::arch::x86_64::sse2::memchr::TwoIter<'a, 'h>

§

impl<'a, 'py> !Send for DowncastError<'a, 'py>

§

impl<'a, 'py> !Send for BorrowedTupleIterator<'a, 'py>

§

impl<'a, 'py, T> !Send for devela::_dep::pyo3::Borrowed<'a, 'py, T>

§

impl<'a, 'py, T> !Send for BoundRef<'a, 'py, T>

§

impl<'a, A> Send for devela::_core::option::Iter<'a, A>
where A: Sync,

§

impl<'a, A> Send for devela::_core::option::IterMut<'a, A>
where A: Send,

§

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

§

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

§

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

§

impl<'a, DST, BUF> !Send for DstQueueIter<'a, DST, BUF>

§

impl<'a, DST, BUF> !Send for DstQueueIterMut<'a, DST, BUF>

§

impl<'a, DST, BUF> !Send for DstQueuePopHandle<'a, DST, BUF>

§

impl<'a, DST, BUF> !Send for DstStackIter<'a, DST, BUF>

§

impl<'a, DST, BUF> !Send for DstStackIterMut<'a, DST, BUF>

§

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 devela::_dep::serde::de::value::StrDeserializer<'a, E>
where E: Send,

§

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

§

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

§

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

§

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

§

impl<'a, K> Send for devela::_dep::_alloc::collections::btree_set::Cursor<'a, K>
where K: Sync,

§

impl<'a, K> Send for devela::_dep::_std::collections::hash_set::Drain<'a, K>
where K: Send,

§

impl<'a, K> Send for devela::_dep::_std::collections::hash_set::Iter<'a, K>
where K: Sync,

§

impl<'a, K> Send for devela::_dep::hashbrown::hash_set::Iter<'a, K>
where K: Sync,

§

impl<'a, K, A> Send for devela::_dep::_alloc::collections::btree_set::CursorMut<'a, K, A>
where A: Send, K: Send,

§

impl<'a, K, A> Send for devela::_dep::_alloc::collections::btree_set::CursorMutKey<'a, K, A>
where A: Send, K: Send,

§

impl<'a, K, A> Send for devela::_dep::hashbrown::hash_set::Drain<'a, K, A>
where A: Send, K: Send,

§

impl<'a, K, F> Send for devela::_dep::_std::collections::hash_set::ExtractIf<'a, K, F>
where F: Send, K: Send,

§

impl<'a, K, F, A> Send for devela::_dep::hashbrown::hash_set::ExtractIf<'a, K, F, A>
where F: Send, A: Send, K: Send,

§

impl<'a, K, V> !Send for devela::_dep::rkyv::collections::swiss_table::index_map::Iter<'a, K, V>

§

impl<'a, K, V> !Send for devela::_dep::rkyv::collections::swiss_table::index_map::Keys<'a, K, V>

§

impl<'a, K, V> !Send for devela::_dep::rkyv::collections::swiss_table::index_map::Values<'a, K, V>

§

impl<'a, K, V> Send for devela::_dep::_std::collections::hash_map::Entry<'a, K, V>
where K: Send, V: Send,

§

impl<'a, K, V> Send for devela::_dep::_alloc::collections::btree_map::Cursor<'a, K, V>
where K: Sync, V: Sync,

§

impl<'a, K, V> Send for devela::_dep::_alloc::collections::btree_map::Iter<'a, K, V>
where K: Sync, V: Sync,

§

impl<'a, K, V> Send for devela::_dep::_alloc::collections::btree_map::IterMut<'a, K, V>
where K: Send, V: Send,

§

impl<'a, K, V> Send for devela::_dep::_alloc::collections::btree_map::Keys<'a, K, V>
where K: Sync, V: Sync,

§

impl<'a, K, V> Send for devela::_dep::_alloc::collections::btree_map::Range<'a, K, V>
where K: Sync, V: Sync,

§

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

§

impl<'a, K, V> Send for devela::_dep::_alloc::collections::btree_map::Values<'a, K, V>
where K: Sync, V: Sync,

§

impl<'a, K, V> Send for devela::_dep::_alloc::collections::btree_map::ValuesMut<'a, K, V>
where K: Send, V: Send,

§

impl<'a, K, V> Send for devela::_dep::_std::collections::hash_map::Drain<'a, K, V>
where K: Send, V: Send,

§

impl<'a, K, V> Send for devela::_dep::_std::collections::hash_map::Iter<'a, K, V>
where K: Sync, V: Sync,

§

impl<'a, K, V> Send for devela::_dep::_std::collections::hash_map::IterMut<'a, K, V>
where K: Send, V: Send,

§

impl<'a, K, V> Send for devela::_dep::_std::collections::hash_map::Keys<'a, K, V>
where K: Sync, V: Sync,

§

impl<'a, K, V> Send for devela::_dep::_std::collections::hash_map::OccupiedEntry<'a, K, V>
where K: Send, V: Send,

§

impl<'a, K, V> Send for devela::_dep::_std::collections::hash_map::OccupiedError<'a, K, V>
where V: Send, K: Send,

§

impl<'a, K, V> Send for devela::_dep::_std::collections::hash_map::VacantEntry<'a, K, V>
where K: Send, V: Send,

§

impl<'a, K, V> Send for devela::_dep::_std::collections::hash_map::Values<'a, K, V>
where K: Sync, V: Sync,

§

impl<'a, K, V> Send for devela::_dep::_std::collections::hash_map::ValuesMut<'a, K, V>
where K: Send, V: Send,

§

impl<'a, K, V> Send for devela::_dep::hashbrown::hash_map::Iter<'a, K, V>
where K: Sync, V: Sync,

§

impl<'a, K, V> Send for devela::_dep::hashbrown::hash_map::Keys<'a, K, V>
where K: Sync, V: Sync,

§

impl<'a, K, V> Send for devela::_dep::hashbrown::hash_map::Values<'a, K, V>
where K: Sync, V: Sync,

§

impl<'a, K, V> Send for devela::_dep::hashbrown::hash_map::ValuesMut<'a, K, V>
where K: Send, V: Send,

§

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

§

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

§

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

§

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

§

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

§

impl<'a, K, V, A> Send for devela::all::BTreeMapEntry<'a, K, V, A>
where K: Send, A: Send, V: Send,

§

impl<'a, K, V, A> Send for devela::_dep::_alloc::collections::btree_map::CursorMut<'a, K, V, A>
where A: Send, K: Send, V: Send,

§

impl<'a, K, V, A> Send for devela::_dep::_alloc::collections::btree_map::CursorMutKey<'a, K, V, A>
where A: Send, K: Send, V: Send,

§

impl<'a, K, V, A> Send for devela::_dep::_alloc::collections::btree_map::OccupiedEntry<'a, K, V, A>
where A: Send, K: Send, V: Send,

§

impl<'a, K, V, A> Send for devela::_dep::_alloc::collections::btree_map::OccupiedError<'a, K, V, A>
where V: Send, A: Send, K: Send,

§

impl<'a, K, V, A> Send for devela::_dep::_alloc::collections::btree_map::VacantEntry<'a, K, V, A>
where K: Send, A: Send, V: Send,

§

impl<'a, K, V, A> Send for devela::_dep::hashbrown::hash_map::Drain<'a, K, V, A>
where A: Send, K: Send, V: Send,

§

impl<'a, K, V, F> Send for devela::_dep::_std::collections::hash_map::ExtractIf<'a, K, V, F>
where F: Send, K: Send, V: Send,

§

impl<'a, K, V, F, A> Send for devela::_dep::_alloc::collections::btree_map::ExtractIf<'a, K, V, F, A>
where F: Send, A: Send, K: Send, V: Send,

§

impl<'a, K, V, F, A> Send for devela::_dep::hashbrown::hash_map::ExtractIf<'a, K, V, F, A>
where F: Send, A: Send, K: Send, V: Send,

§

impl<'a, K, V, H> !Send for devela::_dep::rkyv::collections::swiss_table::map::Iter<'a, K, V, H>

§

impl<'a, K, V, H> !Send for devela::_dep::rkyv::collections::swiss_table::map::IterMut<'a, K, V, H>

§

impl<'a, K, V, H> !Send for devela::_dep::rkyv::collections::swiss_table::map::Keys<'a, K, V, H>

§

impl<'a, K, V, H> !Send for devela::_dep::rkyv::collections::swiss_table::map::Values<'a, K, V, H>

§

impl<'a, K, V, H> !Send for devela::_dep::rkyv::collections::swiss_table::map::ValuesMut<'a, K, V, H>

§

impl<'a, K, V, S> Send for devela::_dep::_std::collections::hash_map::RawEntryMut<'a, K, V, S>
where K: Send, V: Send, S: Send + Sync,

§

impl<'a, K, V, S> Send for devela::_dep::_std::collections::hash_map::RawEntryBuilder<'a, K, V, S>
where S: Sync, K: Sync, V: Sync,

§

impl<'a, K, V, S> Send for devela::_dep::_std::collections::hash_map::RawEntryBuilderMut<'a, K, V, S>
where S: Send, K: Send, V: Send,

§

impl<'a, K, V, S> Send for devela::_dep::_std::collections::hash_map::RawOccupiedEntryMut<'a, K, V, S>
where K: Send, V: Send, S: Send,

§

impl<'a, K, V, S> Send for devela::_dep::_std::collections::hash_map::RawVacantEntryMut<'a, K, V, S>
where S: Sync, K: Send, V: Send,

§

impl<'a, K, V, S, A> Send for devela::_dep::hashbrown::hash_map::RawEntryMut<'a, K, V, S, A>
where K: Send, V: Send, S: Send + Sync, A: Send,

§

impl<'a, K, V, S, A> Send for devela::all::HashMapEntry<'a, K, V, S, A>
where K: Send, V: Send, S: Send, A: Send,

§

impl<'a, K, V, S, A> Send for devela::_dep::hashbrown::hash_map::OccupiedError<'a, K, V, S, A>
where V: Send, K: Send, S: Send, A: Send,

§

impl<'a, K, V, S, A> Send for devela::_dep::hashbrown::hash_map::RawEntryBuilder<'a, K, V, S, A>
where S: Sync, A: Sync, K: Sync, V: Sync,

§

impl<'a, K, V, S, A> Send for devela::_dep::hashbrown::hash_map::RawEntryBuilderMut<'a, K, V, S, A>
where S: Send, A: Send, K: Send, V: Send,

§

impl<'a, K, V, S, A> Send for devela::_dep::hashbrown::hash_map::RawVacantEntryMut<'a, K, V, S, A>
where S: Sync, A: Send, K: Send, V: Send,

§

impl<'a, K, V, S, A> Send for devela::_dep::hashbrown::hash_map::VacantEntry<'a, K, V, S, A>
where K: Send, S: Send, A: Send, V: Send,

§

impl<'a, M> Send for FlatMapSerializeMap<'a, M>
where M: Send,

§

impl<'a, M> Send for FlatMapSerializeStruct<'a, M>
where M: Send,

§

impl<'a, M> Send for FlatMapSerializeStructVariantAsMapValue<'a, M>
where M: Send,

§

impl<'a, M> Send for FlatMapSerializeTupleVariantAsMapValue<'a, M>
where M: Send,

§

impl<'a, M> Send for FlatMapSerializer<'a, M>
where M: Send,

§

impl<'a, Opcode, Value> Send for Updater<'a, Opcode, Value>
where Value: Send, Opcode: Send,

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<'a, P> Send for Contains<'a, P>
where P: Send,

§

impl<'a, P> Send for EndsWith<'a, P>
where P: Send,

§

impl<'a, P> Send for StartsWith<'a, P>
where P: Send,

§

impl<'a, P> Send for StripPrefix<'a, P>
where P: Send,

§

impl<'a, P> Send for StripSuffix<'a, P>
where P: Send,

§

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

§

impl<'a, S> Send for AudioPlanes<'a, S>
where S: Sync,

§

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

§

impl<'a, T> !Send for devela::_dep::_std::sync::mpsc::Iter<'a, T>

§

impl<'a, T> !Send for devela::_dep::_std::sync::mpsc::TryIter<'a, T>

§

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

§

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

§

impl<'a, T> Send for devela::_core::result::Iter<'a, T>
where T: Sync,

§

impl<'a, T> Send for devela::_core::result::IterMut<'a, T>
where T: Send,

§

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

§

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

§

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

§

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

§

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

§

impl<'a, T> Send for devela::_dep::_alloc::collections::binary_heap::Iter<'a, T>
where T: Sync,

§

impl<'a, T> Send for devela::_dep::_alloc::collections::btree_set::Iter<'a, T>
where T: Sync,

§

impl<'a, T> Send for devela::_dep::_alloc::collections::btree_set::Range<'a, T>
where T: Sync,

§

impl<'a, T> Send for devela::_dep::_alloc::collections::btree_set::SymmetricDifference<'a, T>
where T: Sync,

§

impl<'a, T> Send for devela::_dep::_alloc::collections::btree_set::Union<'a, T>
where T: Sync,

§

impl<'a, T> Send for devela::_dep::_alloc::collections::vec_deque::Iter<'a, T>
where T: Sync,

§

impl<'a, T> Send for devela::_dep::_alloc::collections::vec_deque::IterMut<'a, T>
where T: Send,

§

impl<'a, T> Send for devela::_dep::_std::sync::mpmc::Iter<'a, T>
where T: Send,

§

impl<'a, T> Send for devela::_dep::_std::sync::mpmc::TryIter<'a, T>
where T: Send,

§

impl<'a, T> Send for devela::_dep::bumpalo::boxed::Box<'a, T>
where T: Send + ?Sized,

§

impl<'a, T> Send for devela::_dep::hashbrown::hash_table::Iter<'a, T>
where T: Sync,

§

impl<'a, T> Send for devela::_dep::hashbrown::hash_table::IterMut<'a, T>
where T: Send,

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<'a, T, A> Send for devela::_dep::_alloc::collections::btree_set::Entry<'a, T, A>
where A: Send, T: Send,

§

impl<'a, T, A> Send for devela::_dep::hashbrown::hash_table::Entry<'a, T, A>
where T: Send, A: Send,

§

impl<'a, T, A> Send for devela::_dep::_alloc::collections::binary_heap::Drain<'a, T, A>
where T: Send, A: Send,

§

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

§

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

§

impl<'a, T, A> Send for devela::_dep::_alloc::collections::btree_set::Difference<'a, T, A>
where T: Sync, A: Sync,

§

impl<'a, T, A> Send for devela::_dep::_alloc::collections::btree_set::Intersection<'a, T, A>
where T: Sync, A: Sync,

§

impl<'a, T, A> Send for devela::_dep::_alloc::collections::btree_set::OccupiedEntry<'a, T, A>
where A: Send, T: Send,

§

impl<'a, T, A> Send for devela::_dep::_alloc::collections::btree_set::VacantEntry<'a, T, A>
where T: Send, A: Send,

§

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

§

impl<'a, T, A> Send for devela::_dep::hashbrown::hash_table::Drain<'a, T, A>
where T: Send, A: Send,

§

impl<'a, T, A> Send for devela::_dep::hashbrown::hash_table::VacantEntry<'a, T, A>
where T: Send, A: Send,

§

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

§

impl<'a, T, F, A = Global> !Send for devela::_dep::_alloc::collections::linked_list::ExtractIf<'a, T, F, A>

§

impl<'a, T, F, A> Send for devela::_dep::_alloc::collections::btree_set::ExtractIf<'a, T, F, A>
where F: Send, A: Send, T: Send,

§

impl<'a, T, F, A> Send for devela::_dep::_alloc::vec::ExtractIf<'a, T, F, A>
where F: Send, A: Send, T: Send,

§

impl<'a, T, F, A> Send for devela::_dep::hashbrown::hash_table::ExtractIf<'a, T, F, A>
where F: Send, T: Send, A: Send,

§

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

§

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

§

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

§

impl<'a, T, P> Send for devela::_core::slice::SplitInclusive<'a, T, P>
where P: Send, T: Sync,

§

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

§

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

§

impl<'a, T, P> Send for devela::_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, S> Send for devela::_dep::_std::collections::hash_set::Entry<'a, T, S>
where T: Send, S: Send,

§

impl<'a, T, S> Send for devela::_dep::_std::collections::hash_set::Difference<'a, T, S>
where S: Sync, T: Sync,

§

impl<'a, T, S> Send for devela::_dep::_std::collections::hash_set::Intersection<'a, T, S>
where S: Sync, T: Sync,

§

impl<'a, T, S> Send for devela::_dep::_std::collections::hash_set::OccupiedEntry<'a, T, S>
where T: Send, S: Send,

§

impl<'a, T, S> Send for devela::_dep::_std::collections::hash_set::SymmetricDifference<'a, T, S>
where S: Sync, T: Sync,

§

impl<'a, T, S> Send for devela::_dep::_std::collections::hash_set::Union<'a, T, S>
where S: Sync, T: Sync,

§

impl<'a, T, S> Send for devela::_dep::_std::collections::hash_set::VacantEntry<'a, T, S>
where T: Send, S: Send,

§

impl<'a, T, S, A> Send for devela::_dep::hashbrown::hash_set::Entry<'a, T, S, A>
where T: Send, S: Send, A: Send,

§

impl<'a, T, S, A> Send for devela::_dep::hashbrown::hash_set::Difference<'a, T, S, A>
where S: Sync, A: Sync, T: Sync,

§

impl<'a, T, S, A> Send for devela::_dep::hashbrown::hash_set::Intersection<'a, T, S, A>
where S: Sync, A: Sync, T: Sync,

§

impl<'a, T, S, A> Send for devela::_dep::hashbrown::hash_set::OccupiedEntry<'a, T, S, A>
where T: Send, S: Send, A: Send,

§

impl<'a, T, S, A> Send for devela::_dep::hashbrown::hash_set::SymmetricDifference<'a, T, S, A>
where S: Sync, A: Sync, T: Sync,

§

impl<'a, T, S, A> Send for devela::_dep::hashbrown::hash_set::Union<'a, T, S, A>
where S: Sync, A: Sync, T: Sync,

§

impl<'a, T, S, A> Send for devela::_dep::hashbrown::hash_set::VacantEntry<'a, T, S, A>
where T: Send, S: Send, A: Send,

§

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

§

impl<'a, T, const N: usize> Send for devela::_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, _0, _1, _2, _3, _4, _5, _6, _7, _8, _9, _10, _11> Send for TupleElementMut<'a, _0, _1, _2, _3, _4, _5, _6, _7, _8, _9, _10, _11>
where _0: Send, _1: Send, _2: Send, _3: Send, _4: Send, _5: Send, _6: Send, _7: Send, _8: Send, _9: Send, _10: Send, _11: Send,

§

impl<'a, _0, _1, _2, _3, _4, _5, _6, _7, _8, _9, _10, _11> Send for TupleElementRef<'a, _0, _1, _2, _3, _4, _5, _6, _7, _8, _9, _10, _11>
where _0: Sync, _1: Sync, _2: Sync, _3: Sync, _4: Sync, _5: Sync, _6: Sync, _7: Sync, _8: Sync, _9: Sync, _10: Sync, _11: Sync,

§

impl<'a, _0, _1, _2, _3, _4, _5, _6, _7, _8, _9, _10, _11> Send for TupleIterMut<'a, _0, _1, _2, _3, _4, _5, _6, _7, _8, _9, _10, _11>
where _0: Send, _1: Send, _2: Send, _3: Send, _4: Send, _5: Send, _6: Send, _7: Send, _8: Send, _9: Send, _10: Send, _11: Send,

§

impl<'a, _0, _1, _2, _3, _4, _5, _6, _7, _8, _9, _10, _11> Send for TupleIterRef<'a, _0, _1, _2, _3, _4, _5, _6, _7, _8, _9, _10, _11>
where _0: Sync, _1: Sync, _2: Sync, _3: Sync, _4: Sync, _5: Sync, _6: Sync, _7: Sync, _8: Sync, _9: Sync, _10: Sync, _11: Sync,

§

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

§

impl<'b, T> !Send for devela::all::Ref<'b, T>

§

impl<'b, T> !Send for devela::all::RefMut<'b, T>

§

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

§

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

§

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<'bump> !Send for devela::_dep::bumpalo::collections::string::FromUtf8Error<'bump>

§

impl<'bump> !Send for devela::_dep::bumpalo::collections::String<'bump>

§

impl<'bump, T> !Send for devela::_dep::bumpalo::collections::Vec<'bump, T>

§

impl<'c, 'h> Send for SubCaptureMatches<'c, 'h>

§

impl<'ch> Send for devela::_dep::rayon::str::Bytes<'ch>

§

impl<'ch> Send for devela::_dep::rayon::str::CharIndices<'ch>

§

impl<'ch> Send for devela::_dep::rayon::str::Chars<'ch>

§

impl<'ch> Send for devela::_dep::rayon::str::EncodeUtf16<'ch>

§

impl<'ch> Send for devela::_dep::rayon::str::Lines<'ch>

§

impl<'ch> Send for devela::_dep::rayon::str::SplitAsciiWhitespace<'ch>

§

impl<'ch> Send for devela::_dep::rayon::str::SplitWhitespace<'ch>

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<'data, T> Send for AncillaryIter<'data, T>
where T: Send,

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<'de> Send for Content<'de>

§

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

§

impl<'de, E> Send for devela::_dep::serde::de::value::BorrowedStrDeserializer<'de, E>
where E: Send,

§

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

§

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

§

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

§

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

§

impl<'de, T> Send for Borrowed<'de, T>
where T: Sync + ?Sized,

§

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

§

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

§

impl<'fd> Send for PollFd<'fd>

§

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

§

impl<'h> Send for Memchr2<'h>

§

impl<'h> Send for Memchr3<'h>

§

impl<'h> Send for Memchr<'h>

§

impl<'h> Send for Captures<'h>

§

impl<'h> Send for Match<'h>

§

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

§

impl<'h, 'n> Send for FindRevIter<'h, 'n>

§

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

§

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

§

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

§

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

§

impl<'n> Send for devela::_dep::memchr::memmem::Finder<'n>

§

impl<'n> Send for devela::_dep::memchr::memmem::FinderRev<'n>

§

impl<'p> !Send for BoundFrozenSetIterator<'p>

§

impl<'p> !Send for BoundSetIterator<'p>

§

impl<'p, P> Send for ByRef<'p, P>
where P: Send,

§

impl<'p, T> !Send for PyRef<'p, T>

§

impl<'p, T> !Send for PyRefMut<'p, T>

§

impl<'py> !Send for DowncastIntoError<'py>

§

impl<'py> !Send for Python<'py>

§

impl<'py> !Send for BoundDictIterator<'py>

§

impl<'py> !Send for BoundListIterator<'py>

§

impl<'py> !Send for BoundTupleIterator<'py>

§

impl<'py> !Send for PyFrozenSetBuilder<'py>

§

impl<'py, T> !Send for devela::_dep::pyo3::Bound<'py, T>

§

impl<'r> Send for CaptureNames<'r>

§

impl<'r, 'h> Send for CaptureMatches<'r, 'h>

§

impl<'r, 'h> Send for devela::_dep::regex_lite::Matches<'r, 'h>

§

impl<'r, 'h> Send for devela::_dep::regex_lite::Split<'r, 'h>

§

impl<'r, 'h> Send for devela::_dep::regex_lite::SplitN<'r, 'h>

§

impl<'s, T, const CAP: usize, IDX, S> Send for DestaqueIter<'s, T, CAP, IDX, S>
where IDX: Sync, <S as Storage>::Stored<[T; CAP]>: Sync,

§

impl<'s, T, const CAP: usize, IDX, S> Send for StackIter<'s, T, CAP, IDX, S>
where IDX: Sync, <S as Storage>::Stored<[T; CAP]>: Sync,

§

impl<'scope> Send for devela::_dep::rayon::Scope<'scope>

§

impl<'scope> Send for ScopeFifo<'scope>

§

impl<'scope, 'env> Send for devela::work::ThreadScope<'scope, 'env>

§

impl<'scope, T> Send for devela::work::ThreadScopedJoinHandle<'scope, T>
where T: Send,

§

impl<'slice, 'fd> Send for SendAncillaryMessage<'slice, 'fd>

§

impl<'t> Send for TimeZoneFollowingTransitions<'t>

§

impl<'t> Send for TimeZonePrecedingTransitions<'t>

§

impl<'t> Send for TimeZoneTransition<'t>

§

impl<'t> Send for NoExpand<'t>

§

impl<'t, T> Send for OptionFmt<'t, T>
where T: Sync,

§

impl<'t, T, F> Send for OptionFmtOrElse<'t, T, F>
where F: Send, T: Sync,

§

impl<'t, T, U> Send for OptionFmtOr<'t, T, U>
where U: Send, T: Sync,

§

impl<A> !Send for VecChunk<A>

§

impl<A> Send for devela::_core::iter::RepeatN<A>
where A: Send,

§

impl<A> Send for devela::_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> Send for EnumAccessDeserializer<A>
where A: Send,

§

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

§

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

§

impl<A> Send for devela::all::IterRepeat<A>
where A: Send,

§

impl<A, B> Send for devela::_dep::rayon::iter::Chain<A, B>

§

impl<A, B> Send for devela::_dep::rayon::iter::Zip<A, B>

§

impl<A, B> Send for ZipEq<A, B>

§

impl<A, B> Send for devela::all::IterChain<A, B>
where A: Send, B: Send,

§

impl<A, B> Send for devela::all::IterZip<A, B>
where A: Send, B: Send,

§

impl<A, B, C, D, E, F, G, H> Send for Pinned<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, S> Send for Validator<A, S>
where A: Send, S: Send,

§

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

§

impl<B> Send for AudioManagerSettings<B>
where <B as Backend>::Settings: Send,

§

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

§

impl<B> Send for devela::all::IoLines<B>
where B: Send,

§

impl<B> Send for devela::all::IoSplit<B>
where B: Send,

§

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

§

impl<B, M> Send for MonitorStream<B, M>
where B: Send, M: Send,

§

impl<BK, BV, K, V> Send for EntryAdapter<BK, BV, K, V>
where BK: Send, BV: Send, K: Send, V: Send,

§

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

§

impl<ClassT, FieldT, Offset, const IS_PY_T: bool, const IMPLEMENTS_TOPYOBJECT: bool, const IMPLEMENTS_INTOPY: bool, const IMPLEMENTS_INTOPYOBJECT_REF: bool, const IMPLEMENTS_INTOPYOBJECT: bool> Send for PyClassGetterGenerator<ClassT, FieldT, Offset, IS_PY_T, IMPLEMENTS_TOPYOBJECT, IMPLEMENTS_INTOPY, IMPLEMENTS_INTOPYOBJECT_REF, IMPLEMENTS_INTOPYOBJECT>
where ClassT: Send, FieldT: Send, Offset: Send,

§

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

§

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

§

impl<D, S> Send for devela::_dep::rayon::iter::Split<D, S>
where D: Send, S: Send,

§

impl<DST, BUF> !Send for DstQueue<DST, BUF>

§

impl<DST, BUF> !Send for DstStack<DST, BUF>

§

impl<DST, BUF> Send for DstValue<DST, BUF>
where BUF: Send, DST: Send + ?Sized,

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<Error> Send for StreamingSoundData<Error>

§

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

§

impl<F> Send for devela::_core::fmt::FromFn<F>
where F: Send,

§

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

§

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

§

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

§

impl<F> Send for devela::all::IterFromFn<F>
where F: Send,

§

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

§

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

§

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

§

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

§

impl<F, G, H, I, O, O2, E> Send for devela::_dep::winnow::combinator::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 devela::_dep::winnow::combinator::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 ParserIterator<F, I, O, E>
where F: Send, I: Send, O: Send, E: Send,

§

impl<F, I, O, E> Send for devela::_dep::winnow::combinator::Span<F, I, O, E>
where F: Send, I: Send, O: Send, E: Send,

§

impl<F, I, O, E> Send for devela::_dep::winnow::combinator::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, C> Send for devela::_dep::winnow::combinator::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 devela::_dep::winnow::combinator::Value<F, I, O, O2, E>
where F: Send, O2: Send, I: Send, O: Send, E: Send,

§

impl<F, T> Send for devela::_dep::symphonia::core::conv::dither::Identity<F, T>
where F: Send, T: Send,

§

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

§

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

§

impl<F, W> Send for With<F, W>
where F: Send + ?Sized, W: Send,

§

impl<G, C> Send for GcdReturn<G, C>
where G: Send, C: Send,

§

impl<H> Send for BuildHasherDefault<H>

§

impl<I1, I2> Send for devela::_dep::rodio::source::Mix<I1, I2>
where <I2 as Iterator>::Item: Sized + Send, <I1 as Iterator>::Item: Sized + Send, I1: Send, I2: Send,

§

impl<I> Send for devela::_core::async_iter::FromIter<I>
where I: Send,

§

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

§

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

§

impl<I> Send for devela::_dep::rayon::iter::Chunks<I>

§

impl<I> Send for devela::_dep::rayon::iter::Cloned<I>

§

impl<I> Send for devela::_dep::rayon::iter::Copied<I>

§

impl<I> Send for devela::_dep::rayon::iter::Enumerate<I>

§

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

§

impl<I> Send for devela::_dep::rayon::iter::Flatten<I>

§

impl<I> Send for FlattenIter<I>

§

impl<I> Send for devela::_dep::rayon::iter::Intersperse<I>
where <I as ParallelIterator>::Item: Sized,

§

impl<I> Send for MaxLen<I>

§

impl<I> Send for MinLen<I>

§

impl<I> Send for PanicFuse<I>

§

impl<I> Send for devela::_dep::rayon::iter::Rev<I>

§

impl<I> Send for devela::_dep::rayon::iter::Skip<I>
where I: Send,

§

impl<I> Send for SkipAny<I>

§

impl<I> Send for devela::_dep::rayon::iter::StepBy<I>

§

impl<I> Send for devela::_dep::rayon::iter::Take<I>
where I: Send,

§

impl<I> Send for TakeAny<I>

§

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

§

impl<I> Send for WhileSome<I>

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<I> Send for devela::_dep::rodio::source::FromIter<I>
where I: Send, <I as Iterator>::Item: Send,

§

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

§

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

§

impl<I> Send for devela::_dep::rodio::source::Repeat<I>
where <I as Iterator>::Item: Sized + Sync + Send, I: Send,

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<I> Send for TrackPosition<I>
where I: 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> Send for devela::all::IterCloned<I>
where I: Send,

§

impl<I> Send for devela::all::IterCopied<I>
where I: Send,

§

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

§

impl<I> Send for devela::all::IterEnumerate<I>
where I: Send,

§

impl<I> Send for devela::all::IterFlatten<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 Peekable<I>
where I: Send, <I as Iterator>::Item: Send,

§

impl<I> Send for devela::all::IterSkip<I>
where I: Send,

§

impl<I> Send for devela::all::IterStepBy<I>
where I: Send,

§

impl<I> Send for devela::all::IterTake<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, D> Send for SamplesConverter<I, D>
where I: Send, D: Send,

§

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

§

impl<I, E> Send for SeqDeserializer<I, E>
where E: Send, I: Send,

§

impl<I, E> Send for ParseError<I, E>
where I: Send, E: Send,

§

impl<I, F> Send for devela::_dep::rayon::iter::FlatMap<I, F>
where F: Send,

§

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

§

impl<I, F> Send for devela::_dep::rayon::iter::Inspect<I, F>
where F: Send,

§

impl<I, F> Send for devela::_dep::rayon::iter::Map<I, F>
where F: Send,

§

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

§

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

§

impl<I, F> Send for devela::all::IterFilterMap<I, F>
where I: Send, F: Send,

§

impl<I, F> Send for devela::all::IterInspect<I, F>
where I: Send, F: Send,

§

impl<I, F> Send for devela::all::IterMap<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, 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 devela::_dep::rayon::iter::Filter<I, P>
where P: Send,

§

impl<I, P> Send for devela::_dep::rayon::iter::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, P> Send for devela::all::IterFilter<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, P, O> Send for Replace<I, P, O>
where I: Send, P: Send, O: Send,

§

impl<I, S> Send for Stateful<I, S>
where I: Send, S: Send,

§

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

§

impl<I, T, F> Send for MapWith<I, T, F>
where T: Send, F: Send,

§

impl<I, U, F> Send for FoldChunksWith<I, U, F>
where U: Send, F: Send,

§

impl<I, U, F> Send for FoldWith<I, U, F>
where I: Send, U: Send, F: Send,

§

impl<I, U, F> Send for TryFoldWith<I, U, F>
where I: Send, <U as Try>::Output: Send, F: Send,

§

impl<I, U, F> Send for devela::all::IterFlatMap<I, U, F>
where <U as IntoIterator>::IntoIter: Send, I: 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<I, const N: usize> Send for devela::_core::iter::ArrayChunks<I, N>
where I: Send, <I as Iterator>::Item: Send,

§

impl<Idx> Send for devela::_core::range::Range<Idx>
where Idx: Send,

§

impl<Idx> Send for devela::_core::range::RangeFrom<Idx>
where Idx: Send,

§

impl<Idx> Send for devela::_core::range::RangeInclusive<Idx>
where Idx: Send,

§

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

§

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

§

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

§

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

§

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

§

impl<Iter> Send for IterBridge<Iter>
where Iter: Send,

§

impl<K> Send for devela::_dep::_std::collections::hash_set::IntoIter<K>
where K: Send,

§

impl<K, A> Send for devela::_dep::hashbrown::hash_set::IntoIter<K, A>
where A: Send, K: Send,

§

impl<K, H> Send for ArchivedHashSet<K, H>
where H: Send, K: Send,

§

impl<K, H> Send for ArchivedIndexSet<K, H>
where H: Send, K: Send,

§

impl<K, V> Send for devela::_dep::_std::collections::hash_map::IntoIter<K, V>
where K: Send, V: Send,

§

impl<K, V> Send for devela::_dep::_std::collections::hash_map::IntoKeys<K, V>
where K: Send, V: Send,

§

impl<K, V> Send for devela::_dep::_std::collections::hash_map::IntoValues<K, V>
where K: Send, V: Send,

§

impl<K, V> Send for devela::_dep::rayon::collections::btree_map::IntoIter<K, V>

§

impl<K, V> Send for devela::_dep::rayon::collections::hash_map::IntoIter<K, V>

§

impl<K, V> Send for devela::_dep::rkyv::collections::util::Entry<K, V>
where K: Send, V: Send,

§

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

§

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

§

impl<K, V, A> Send for devela::_dep::_alloc::collections::btree_map::IntoIter<K, V, A>
where A: Send, K: Send, V: Send,

§

impl<K, V, A> Send for devela::_dep::_alloc::collections::btree_map::IntoKeys<K, V, A>
where A: Send, K: Send, V: Send,

§

impl<K, V, A> Send for devela::_dep::_alloc::collections::btree_map::IntoValues<K, V, A>
where A: Send, K: Send, V: Send,

§

impl<K, V, A> Send for devela::_dep::hashbrown::hash_map::IntoIter<K, V, A>
where A: Send, K: Send, V: Send,

§

impl<K, V, A> Send for devela::_dep::hashbrown::hash_map::IntoKeys<K, V, A>
where A: Send, K: Send, V: Send,

§

impl<K, V, A> Send for devela::_dep::hashbrown::hash_map::IntoValues<K, V, A>
where A: Send, K: Send, V: Send,

§

impl<K, V, A> Send for BTreeMap<K, V, A>
where A: Send, K: Send, V: Send,

§

impl<K, V, H> Send for ArchivedHashMap<K, V, H>
where H: Send, K: Send, V: Send,

§

impl<K, V, H> Send for ArchivedIndexMap<K, V, H>
where H: Send, K: Send, V: Send,

§

impl<K, V, S> Send for devela::_dep::_std::collections::HashMap<K, V, S>
where S: Send, K: Send, V: Send,

§

impl<K, V, S, A> Send for devela::all::HashMap<K, V, S, A>
where S: Send, A: Send, K: Send, V: Send,

§

impl<K, V, const E: usize> Send for ArchivedBTreeMap<K, V, E>
where K: Send, V: Send,

§

impl<K, const E: usize> Send for ArchivedBTreeSet<K, E>
where K: Send,

§

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

§

impl<N> Send for NicheInto<N>
where N: Send + ?Sized,

§

impl<N, H> Send for Mismatch<N, H>
where N: Send, H: Send,

§

impl<O> Send for RawRelPtr<O>
where O: Send,

§

impl<Ok, Error> Send for Impossible<Ok, Error>
where Ok: Send, Error: Send,

§

impl<Opcode> Send for IntegerSetter<Opcode>
where Opcode: Send,

§

impl<Opcode> Send for NoArg<Opcode>
where Opcode: Send,

§

impl<Opcode, Input> Send for Setter<Opcode, Input>
where Input: Send, Opcode: Send,

§

impl<Opcode, Output> Send for Getter<Opcode, Output>
where Opcode: Send, Output: Send,

§

impl<P> Send for devela::_dep::rkyv::option::Iter<P>
where P: Send,

§

impl<P, I, O, C, E> Send for devela::_dep::winnow::combinator::Repeat<P, I, O, C, E>
where P: Send, I: Send, O: Send, C: 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<Ptr> Send for Pin<Ptr>
where Ptr: Send,

§

impl<R> Send for BlockRng64<R>
where <R as BlockRngCore>::Results: Send, R: Send + ?Sized,

§

impl<R> Send for BlockRng<R>
where <R as BlockRngCore>::Results: Send, R: Send + ?Sized,

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<R> Send for devela::_dep::tokio::io::BufReader<R>
where R: Send,

§

impl<R> Send for devela::_dep::tokio::io::Lines<R>
where R: Send,

§

impl<R> Send for devela::_dep::tokio::io::Split<R>
where R: Send,

§

impl<R> Send for devela::_dep::tokio::io::Take<R>
where R: Send,

§

impl<R> Send for devela::all::IoBufReader<R>
where R: Send + ?Sized,

§

impl<R> Send for devela::all::IoBytes<R>
where R: Send,

§

impl<R, W> Send for devela::_dep::tokio::io::Join<R, W>
where R: Send, W: Send,

§

impl<RW> Send for BufStream<RW>
where RW: Send,

§

impl<S = DefaultSpawn> !Send for ThreadPoolBuilder<S>

§

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

§

impl<S> Send for DynamicMixer<S>

§

impl<S> Send for DynamicMixerController<S>

§

impl<S> Send for SourcesQueueInput<S>

§

impl<S> Send for SourcesQueueOutput<S>

§

impl<S> Send for devela::_dep::rodio::source::Empty<S>
where S: Send,

§

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

§

impl<S> Send for devela::_dep::rodio::source::Zero<S>
where S: Send,

§

impl<S> Send for StaticSamplesBuffer<S>
where S: Sync,

§

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

§

impl<S> Send for RawSampleBuffer<S>
where S: Send, <S as RawSample>::RawType: Send,

§

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

§

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

§

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

§

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

§

impl<S, V> Send for Own<S, V>
where S: Send, V: Send,

§

impl<SO> Send for AtomicLoad<SO>
where SO: Send,

§

impl<T0> Send for ArchivedTuple1<T0>
where T0: Send,

§

impl<T0, T1> Send for ArchivedTuple2<T0, T1>
where T0: Send, T1: Send,

§

impl<T0, T1, T2> Send for ArchivedTuple3<T0, T1, T2>
where T0: Send, T1: Send, T2: Send,

§

impl<T0, T1, T2, T3> Send for ArchivedTuple4<T0, T1, T2, T3>
where T0: Send, T1: Send, T2: Send, T3: Send,

§

impl<T0, T1, T2, T3, T4> Send for ArchivedTuple5<T0, T1, T2, T3, T4>
where T0: Send, T1: Send, T2: Send, T3: Send, T4: Send,

§

impl<T0, T1, T2, T3, T4, T5> Send for ArchivedTuple6<T0, T1, T2, T3, T4, T5>
where T0: Send, T1: Send, T2: Send, T3: Send, T4: Send, T5: Send,

§

impl<T0, T1, T2, T3, T4, T5, T6> Send for ArchivedTuple7<T0, T1, T2, T3, T4, T5, T6>
where T0: Send, T1: Send, T2: Send, T3: Send, T4: Send, T5: Send, T6: Send,

§

impl<T0, T1, T2, T3, T4, T5, T6, T7> Send for ArchivedTuple8<T0, T1, T2, T3, T4, T5, T6, T7>
where T0: Send, T1: Send, T2: Send, T3: Send, T4: Send, T5: Send, T6: Send, T7: Send,

§

impl<T0, T1, T2, T3, T4, T5, T6, T7, T8> Send for ArchivedTuple9<T0, T1, T2, T3, T4, T5, T6, T7, T8>
where T0: Send, T1: Send, T2: Send, T3: Send, T4: Send, T5: Send, T6: Send, T7: Send, T8: Send,

§

impl<T0, T1, T2, T3, T4, T5, T6, T7, T8, T9> Send for ArchivedTuple10<T0, T1, T2, T3, T4, T5, T6, T7, T8, T9>
where T0: Send, T1: Send, T2: Send, T3: Send, T4: Send, T5: Send, T6: Send, T7: Send, T8: Send, T9: Send,

§

impl<T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10> Send for ArchivedTuple11<T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10>
where T0: Send, T1: Send, T2: Send, T3: Send, T4: Send, T5: Send, T6: Send, T7: Send, T8: Send, T9: Send, T10: Send,

§

impl<T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11> Send for ArchivedTuple12<T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11>
where T0: Send, T1: Send, T2: Send, T3: Send, T4: Send, T5: Send, T6: Send, T7: Send, T8: Send, T9: Send, T10: Send, T11: Send,

§

impl<T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12> Send for ArchivedTuple13<T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12>
where T0: Send, T1: Send, T2: Send, T3: Send, T4: Send, T5: Send, T6: Send, T7: Send, T8: Send, T9: Send, T10: Send, T11: Send, T12: Send,

§

impl<T1, T2> Send for Compare<T1, T2>
where T1: Send, T2: Send,

§

impl<T1, T2> Send for EqIgnoreAsciiCase<T1, T2>
where T1: Send, T2: Send,

§

impl<T1, T2> Send for Equal<T1, T2>
where T1: Send, T2: Send,

§

impl<T> !Send for RawIter<T>

§

impl<T> !Send for Place<T>

§

impl<T> !Send for Closure<T>

§

impl<T> !Send for RcRef<T>

§

impl<T> !Send for RcRefMut<T>

§

impl<T> Send for Option<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 devela::_dep::kira::Value<T>
where T: Send,

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<T> Send for AsyncDropInPlace<T>
where <T as AsyncDestruct>::AsyncDestructor: Send, T: ?Sized,

§

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

§

impl<T> Send for devela::_core::result::IntoIter<T>
where T: Send,

§

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

§

impl<T> Send for devela::_dep::_std::sync::mpmc::IntoIter<T>
where T: Send,

§

impl<T> Send for devela::_dep::_std::sync::mpmc::SendError<T>
where T: Send,

§

impl<T> Send for devela::_dep::_std::sync::mpsc::IntoIter<T>
where T: Send,

§

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

§

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

§

impl<T> Send for CommandReader<T>

§

impl<T> Send for CommandWriter<T>

§

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

§

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

§

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

§

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

§

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

§

impl<T> Send for MidiInputConnection<T>

§

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

§

impl<T> Send for PyClassInitializer<T>
where T: Send, <<T as PyClassImpl>::BaseType as PyClassBaseType>::Initializer: Send,

§

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

§

impl<T> Send for devela::_dep::rayon::collections::binary_heap::IntoIter<T>

§

impl<T> Send for devela::_dep::rayon::collections::btree_set::IntoIter<T>

§

impl<T> Send for devela::_dep::rayon::collections::hash_set::IntoIter<T>

§

impl<T> Send for devela::_dep::rayon::collections::linked_list::IntoIter<T>

§

impl<T> Send for devela::_dep::rayon::collections::vec_deque::IntoIter<T>

§

impl<T> Send for devela::_dep::rayon::iter::Empty<T>

§

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

§

impl<T> Send for devela::_dep::rayon::iter::Once<T>

§

impl<T> Send for devela::_dep::rayon::iter::Repeat<T>

§

impl<T> Send for devela::_dep::rayon::iter::RepeatN<T>

§

impl<T> Send for devela::_dep::rayon::option::IntoIter<T>

§

impl<T> Send for devela::_dep::rayon::range::Iter<T>
where T: Send,

§

impl<T> Send for devela::_dep::rayon::range_inclusive::Iter<T>
where T: Send,

§

impl<T> Send for devela::_dep::rayon::result::IntoIter<T>

§

impl<T> Send for devela::_dep::rayon::vec::IntoIter<T>

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<T> Send for devela::_dep::rkyv::with::Map<T>
where T: Send,

§

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

§

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

§

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

§

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

§

impl<T> Send for WasmRet<T>
where <T as WasmAbi>::Prim1: Send, <T as WasmAbi>::Prim2: Send, <T as WasmAbi>::Prim3: Send, <T as WasmAbi>::Prim4: Send,

§

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

§

impl<T> Send for JsStatic<T>

§

impl<T> Send for JsThreadLocal<T>

§

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

§

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

§

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

§

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

§

impl<T> Send for devela::num::Compare<T>
where T: Send,

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<T> Send for devela::work::Atomic<T>
where T: Send,

§

impl<T> Send for devela::work::AtomicPtr<T>

§

impl<T> Send for Pending<T>

§

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

§

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

§

impl<T> Send for LocalKey<T>

§

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

§

impl<T> Send for ArchivedBareBox<T>
where <T as Archive>::Archived: Send,

§

impl<T> Send for BareBoxResolver<T>
where <T as Archive>::Resolver: Send,

§

impl<T> Send for Discriminant<T>

§

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

§

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

§

impl<T> Send for devela::all::IoCursor<T>
where T: Send,

§

impl<T> Send for devela::all::IoTake<T>
where T: Send,

§

impl<T> Send for devela::all::IterEmpty<T>

§

impl<T> Send for devela::all::IterOnce<T>
where T: Send,

§

impl<T> Send for devela::all::IterRev<T>
where T: Send,

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<T> Send for TypeResource<T>
where <T as TypeResourced>::TypeData: Send,

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<T> Send for PyClassObject<T>
where <<T as PyClassImpl>::BaseType as PyClassBaseType>::LayoutAsBase: Send, <<T as PyClassImpl>::PyClassMutability as PyClassMutability>::Storage: Send, <T as PyClassImpl>::ThreadChecker: Send, <T as PyClassImpl>::Dict: Send, <T as PyClassImpl>::WeakRef: Send, T: Send,

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<T, A> Send for devela::_dep::_alloc::collections::binary_heap::IntoIter<T, A>
where T: Send, A: Send,

§

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

§

impl<T, A> Send for devela::_dep::_alloc::collections::btree_set::IntoIter<T, A>
where A: Send, T: Send,

§

impl<T, A> Send for devela::_dep::_alloc::collections::linked_list::IntoIter<T, A>
where T: Send, A: Send,

§

impl<T, A> Send for devela::_dep::_alloc::collections::vec_deque::IntoIter<T, A>
where A: Send, T: Send,

§

impl<T, A> Send for devela::_dep::hashbrown::hash_table::IntoIter<T, A>
where T: Send, A: Send,

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<T, D> Send for Storage<T, D>
where T: Send, D: Send,

§

impl<T, E> !Send for CoroRun<T, E>

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<T, P> Send for Split<T, P>
where T: Send, P: Send,

§

impl<T, S> Send for devela::_dep::_std::collections::HashSet<T, S>
where S: Send, T: Send,

§

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

§

impl<T, S, A> Send for devela::all::HashSet<T, S, A>
where S: Send, A: Send, T: Send,

§

impl<T, U> Send for devela::all::IoChain<T, U>
where T: Send, U: Send,

§

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

§

impl<T, const C: usize, const R: usize, const CR: usize, const RMAJ: bool = true, S = ()> !Send for ArchivedArray2d<T, C, R, CR, RMAJ, S>

§

impl<T, const C: usize, const R: usize, const CR: usize, const RMAJ: bool = true, S = ()> !Send for Array2dResolver<T, C, R, CR, RMAJ, S>

§

impl<T, const C: usize, const R: usize, const CR: usize, const RMAJ: bool, S> Send for Array2d<T, C, R, CR, RMAJ, S>
where <S as Storage>::Stored<[T; CR]>: Send,

§

impl<T, const CAP: usize> Send for DstArray<T, CAP>
where T: Send,

§

impl<T, const CAP: usize, IDX, S = ()> !Send for ArchivedDestaque<T, CAP, IDX, S>

§

impl<T, const CAP: usize, IDX, S = ()> !Send for ArchivedStack<T, CAP, IDX, S>

§

impl<T, const CAP: usize, IDX, S = ()> !Send for DestaqueResolver<T, CAP, IDX, S>

§

impl<T, const CAP: usize, IDX, S = ()> !Send for StackResolver<T, CAP, IDX, S>

§

impl<T, const CAP: usize, IDX, S> Send for Destaque<T, CAP, IDX, S>
where IDX: Send, <S as Storage>::Stored<[T; CAP]>: Send,

§

impl<T, const CAP: usize, IDX, S> Send for Stack<T, CAP, IDX, S>
where IDX: Send, <S as Storage>::Stored<[T; CAP]>: Send,

§

impl<T, const CAP: usize, S> Send for ArchivedArray<T, CAP, S>
where <<S as Storage>::Stored<[T; CAP]> as Archive>::Archived: Send,

§

impl<T, const CAP: usize, S> Send for devela::all::Array<T, CAP, S>
where <S as Storage>::Stored<[T; CAP]>: Send,

§

impl<T, const CAP: usize, S> Send for ArrayResolver<T, CAP, S>
where <<S as Storage>::Stored<[T; CAP]> as Archive>::Resolver: Send,

§

impl<T, const CAP: usize, S> Send for ArrayUninit<T, CAP, S>
where <S as Storage>::Stored<[MaybeUninit<T>; CAP]>: Send,

§

impl<T, const D: usize> Send for Extent<T, D>
where T: Send,

§

impl<T, const D: usize> Send for Point<T, D>
where T: Send,

§

impl<T, const D: usize> Send for VecPoints<T, D>
where T: Send,

§

impl<T, const D: usize> Send for Vector<T, D>
where T: Send,

§

impl<T, const D: usize, const N: usize> Send for Points<T, D, 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<T, const N: usize> Send for devela::_dep::rayon::array::IntoIter<T, N>

§

impl<T, const N: usize> Send for devela::all::ArrayIntoIter<T, N>
where T: Send,

§

impl<V, Q> Send for ValueQuant<V, Q>
where V: Send, Q: Send,

§

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

§

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

§

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

§

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

§

impl<W> Send for devela::_dep::tokio::io::BufWriter<W>
where W: Send,

§

impl<W> Send for devela::all::IoBufWriter<W>
where W: Send + ?Sized,

§

impl<W> Send for LineWriter<W>
where W: Send + ?Sized,

§

impl<W, A, S> Send for Serializer<W, A, S>
where W: Send, A: Send, S: Send,

§

impl<W, N> Send for MapNiche<W, N>
where W: Send + ?Sized, N: Send + ?Sized,

§

impl<Y, MO, D, H, M, S, MS, US, NS> Send for TimeSplit<Y, MO, D, H, M, S, MS, US, NS>
where Y: Send, MO: Send, D: Send, H: Send, M: Send, S: Send, MS: Send, US: Send, NS: Send,

§

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

§

impl<_0, _1, _2, _3, _4, _5, _6, _7, _8, _9, _10, _11> Send for TupleElement<_0, _1, _2, _3, _4, _5, _6, _7, _8, _9, _10, _11>
where _0: Send, _1: Send, _2: Send, _3: Send, _4: Send, _5: Send, _6: Send, _7: Send, _8: Send, _9: Send, _10: Send, _11: Send,

§

impl<_0, _1, _2, _3, _4, _5, _6, _7, _8, _9, _10, _11> Send for TupleIter<_0, _1, _2, _3, _4, _5, _6, _7, _8, _9, _10, _11>
where _0: Send, _1: Send, _2: Send, _3: Send, _4: Send, _5: Send, _6: Send, _7: Send, _8: Send, _9: Send, _10: Send, _11: Send,

§

impl<const CAP: usize> Send for GraphemeNonul<CAP>

§

impl<const CAP: usize> Send for GraphemeU8<CAP>

§

impl<const CAP: usize> Send for StringNonul<CAP>

§

impl<const CAP: usize> Send for StringU8<CAP>

§

impl<const CAP: usize> Send for StringU16<CAP>

§

impl<const CAP: usize> Send for StringU32<CAP>

§

impl<const CAP: usize> Send for StringUsize<CAP>

§

impl<const GROUP: u8, const NUM: u8, Data> Send for NoneOpcode<GROUP, NUM, Data>
where Data: Send,

§

impl<const GROUP: u8, const NUM: u8, Data> Send for ReadOpcode<GROUP, NUM, Data>
where Data: Send,

§

impl<const GROUP: u8, const NUM: u8, Data> Send for ReadWriteOpcode<GROUP, NUM, Data>
where Data: Send,

§

impl<const GROUP: u8, const NUM: u8, Data> Send for WriteOpcode<GROUP, NUM, Data>
where Data: Send,

§

impl<const IMPLEMENTS_INTOPYOBJECT_REF: bool, const IMPLEMENTS_INTOPYOBJECT: bool> Send for ConvertField<IMPLEMENTS_INTOPYOBJECT_REF, IMPLEMENTS_INTOPYOBJECT>

§

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

§

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

§

impl<const OPCODE: u32> Send for BadOpcode<OPCODE>

§

impl<const SH1: usize, const SH2: usize, const SH3: usize> Send for XorShift8Custom<SH1, SH2, SH3>

§

impl<const V: i8> Send for devela::_info::examples::niche::NonValueI8<V>

§

impl<const V: i8> Send for devela::all::NonValueI8<V>

§

impl<const V: u8> Send for NonValueU8<V>

§

impl<const V: u16> Send for NonValueU16<V>