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

impl !Send for Arguments<'_>

1.26.0 · Source§

impl !Send for Args

1.26.0 · Source§

impl !Send for ArgsOs

§

impl Send for FltkError

§

impl Send for RawId

§

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

This does not auto-derive because User’s data fields can be used to store pointers to types that are !Send. Dereferencing these as pointers requires using unsafe and ensuring your own safety guarantees.

§

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

This does not auto-derive because User’s data fields can be used to store pointers to types that are !Send. Dereferencing these as pointers requires using unsafe and ensuring your own safety guarantees.

Source§

impl Send for ExampleEnumIntU8

Available on doc or test 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 Browser

§

impl Send for CheckBrowser

§

impl Send for FileBrowser

§

impl Send for HoldBrowser

§

impl Send for MultiBrowser

§

impl Send for SelectBrowser

§

impl Send for devela::_dep::fltk::button::Button

§

impl Send for CheckButton

§

impl Send for LightButton

§

impl Send for RadioButton

§

impl Send for RadioLightButton

§

impl Send for RadioRoundButton

§

impl Send for RepeatButton

§

impl Send for ReturnButton

§

impl Send for RoundButton

§

impl Send for ShortcutButton

§

impl Send for ToggleButton

§

impl Send for Offscreen

§

impl Send for devela::_dep::fltk::frame::Frame

§

impl Send for ColorChooser

§

impl Send for Flex

§

impl Send for Grid

§

impl Send for devela::_dep::fltk::group::Group

§

impl Send for Pack

§

impl Send for Scroll

§

impl Send for Tabs

§

impl Send for Tile

§

impl Send for Wizard

§

impl Send for AnimGifImage

§

impl Send for BmpImage

§

impl Send for GifImage

§

impl Send for IcoImage

§

impl Send for Image

§

impl Send for JpegImage

§

impl Send for Pixmap

§

impl Send for PngImage

§

impl Send for PnmImage

§

impl Send for RgbImage

§

impl Send for SharedImage

§

impl Send for SvgImage

§

impl Send for TiledImage

§

impl Send for XbmImage

§

impl Send for XpmImage

§

impl Send for FileInput

§

impl Send for FloatInput

§

impl Send for Input

§

impl Send for IntInput

§

impl Send for MultilineInput

§

impl Send for SecretInput

§

impl Send for Choice

§

impl Send for MenuBar

§

impl Send for MenuButton

§

impl Send for MenuItem

§

impl Send for SysMenuBar

§

impl Send for Chart

§

impl Send for Clock

§

impl Send for HelpView

§

impl Send for InputChoice

§

impl Send for Progress

§

impl Send for Spinner

§

impl Send for MultilineOutput

§

impl Send for devela::_dep::fltk::output::Output

§

impl Send for devela::_dep::fltk::table::Table

§

impl Send for TableRow

§

impl Send for Terminal

§

impl Send for SimpleTerminal

§

impl Send for TextBuffer

§

impl Send for TextDisplay

§

impl Send for TextEditor

§

impl Send for Tree

§

impl Send for TreeItem

§

impl Send for Adjuster

§

impl Send for Counter

§

impl Send for Dial

§

impl Send for FillDial

§

impl Send for FillSlider

§

impl Send for HorFillSlider

§

impl Send for HorNiceSlider

§

impl Send for HorSlider

§

impl Send for HorValueSlider

§

impl Send for LineDial

§

impl Send for NiceSlider

§

impl Send for Roller

§

impl Send for Scrollbar

§

impl Send for Slider

§

impl Send for ValueInput

§

impl Send for ValueOutput

§

impl Send for ValueSlider

§

impl Send for Widget

§

impl Send for WidgetTracker

§

impl Send for DoubleWindow

§

impl Send for MenuWindow

§

impl Send for OverlayWindow

§

impl Send for SingleWindow

§

impl Send for PyBackedBytes

§

impl Send for PyBackedStr

§

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

§

impl Send for AbortHandle

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 Select<'_>

§

impl Send for Seq

§

impl Send for Unparker

§

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

1.44.0 · Source§

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

1.44.0 · Source§

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

§

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 devela::_dep::tokio::sync::MappedMutexGuard<'a, T>
where T: Send + 'a + ?Sized,

§

impl<'a, T> Send for devela::_dep::ureq::http::header::Drain<'a, T>
where T: Send,

§

impl<'a, T> Send for devela::_dep::ureq::http::header::Iter<'a, T>
where T: Sync,

§

impl<'a, T> Send for devela::_dep::ureq::http::header::IterMut<'a, T>
where T: Send,

§

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

§

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

§

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

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

A MutexGuard is not Send to maximize platform portablity.

On platforms that use POSIX threads (commonly referred to as pthreads) there is a requirement to release mutex locks on the same thread they were acquired. For this reason, MutexGuard must not implement Send to prevent it being dropped from another thread.

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

1.0.0 · Source§

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

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 devela::_dep::fltk::app::Receiver<T>
where T: Send + Sync,

§

impl<T> Send for devela::_dep::fltk::app::Sender<T>
where T: Send + Sync,

§

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 ReadHalf<T>
where T: Send,

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<T> Send for devela::all::ArcWeak<T>
where T: Sync + Send + ?Sized,

1.0.0 · Source§

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

1.0.0 · Source§

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

T must be Send for a Mutex to be Send because it is possible to acquire the owned T from the Mutex via into_inner.

1.28.0 · Source§

impl<T> Send for NonZero<T>

1.70.0 · Source§

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

1.0.0 · Source§

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

1.0.0 · Source§

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

1.29.0 · Source§

impl<T> Send for devela::all::ThreadJoinHandle<T>

§

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 Receiver<T>
where T: Send,

§

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

§

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

§

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

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

1.4.0 · Source§

impl<T, A> Send for devela::_dep::_alloc::sync::Weak<T, A>
where T: Sync + Send + ?Sized, 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 LinkedList<T, A>
where T: Send, A: Allocator + Send,

§

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

§

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

§

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

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.

Auto implementors§

§

impl !Send for BoxBytes

§

impl !Send for Preferences

§

impl !Send for FileChooser

§

impl !Send for FileDialog

§

impl !Send for HelpDialog

§

impl !Send for devela::_dep::fltk::draw::Region

§

impl !Send for Printer

§

impl !Send for ImageSurface

§

impl !Send for SvgFileSurface

§

impl !Send for Utf8Char

§

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 devela::_dep::js_sys::WebAssembly::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 devela::_dep::js_sys::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 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 devela::_dep::rustix::io_uring::iovec

§

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

§

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

§

impl !Send for __kernel_sockaddr_storage

§

impl !Send for PrctlMmMap

§

impl !Send for WaitidStatus

§

impl !Send for AudioCVT

§

impl !Send for devela::_dep::sdl2::audio::AudioSpecWAV

§

impl !Send for devela::_dep::sdl2::clipboard::ClipboardUtil

§

impl !Send for GameController

§

impl !Send for FPSManager

§

impl !Send for devela::_dep::sdl2::haptic::Haptic

§

impl !Send for devela::_dep::sdl2::joystick::Joystick

§

impl !Send for devela::_dep::sdl2::keyboard::KeyboardUtil

§

impl !Send for devela::_dep::sdl2::keyboard::TextInputUtil

§

impl !Send for Dl_info

§

impl !Send for addrinfo

§

impl !Send for aiocb

§

impl !Send for dl_phdr_info

§

impl !Send for ff_periodic_effect

§

impl !Send for glob64_t

§

impl !Send for glob_t

§

impl !Send for group

§

impl !Send for hostent

§

impl !Send for if_nameindex

§

impl !Send for ifaddrs

§

impl !Send for ifconf

§

impl !Send for ifreq

§

impl !Send for devela::_dep::sdl2::libc::iovec

§

impl !Send for iw_event

§

impl !Send for iw_point

§

impl !Send for iwreq

§

impl !Send for lconv

§

impl !Send for mcontext_t

§

impl !Send for mmsghdr

§

impl !Send for mntent

§

impl !Send for devela::_dep::sdl2::libc::msghdr

§

impl !Send for option

§

impl !Send for passwd

§

impl !Send for posix_spawn_file_actions_t

§

impl !Send for protoent

§

impl !Send for regex_t

§

impl !Send for rtentry

§

impl !Send for servent

§

impl !Send for sigevent

§

impl !Send for sigval

§

impl !Send for sock_fprog

§

impl !Send for spwd

§

impl !Send for stack_t

§

impl !Send for tm

§

impl !Send for ucontext_t

§

impl !Send for user

§

impl !Send for devela::_dep::sdl2::mixer::Chunk

§

impl !Send for devela::_dep::sdl2::mouse::Cursor

§

impl !Send for devela::_dep::sdl2::mouse::MouseUtil

§

impl !Send for devela::_dep::sdl2::pixels::Palette

§

impl !Send for devela::_dep::sdl2::pixels::PixelFormat

§

impl !Send for CanvasBuilder

§

impl !Send for devela::_dep::sdl2::AudioSubsystem

§

impl !Send for devela::_dep::sdl2::EventPump

§

impl !Send for devela::_dep::sdl2::EventSubsystem

§

impl !Send for GameControllerSubsystem

§

impl !Send for devela::_dep::sdl2::HapticSubsystem

§

impl !Send for devela::_dep::sdl2::JoystickSubsystem

§

impl !Send for devela::_dep::sdl2::Sdl

§

impl !Send for devela::_dep::sdl2::SensorSubsystem

§

impl !Send for TimerSubsystem

§

impl !Send for devela::_dep::sdl2::VideoSubsystem

§

impl !Send for Mix_Chunk

§

impl !Send for Depth

§

impl !Send for devela::_dep::sdl2::sys::SDL_AssertData

§

impl !Send for SDL_AudioCVT

§

impl !Send for devela::_dep::sdl2::sys::SDL_AudioSpec

§

impl !Send for devela::_dep::sdl2::sys::SDL_DisplayMode

§

impl !Send for devela::_dep::sdl2::sys::SDL_DropEvent

§

impl !Send for devela::_dep::sdl2::sys::SDL_HapticCustom

§

impl !Send for devela::_dep::sdl2::sys::SDL_Locale

§

impl !Send for devela::_dep::sdl2::sys::SDL_MessageBoxButtonData

§

impl !Send for devela::_dep::sdl2::sys::SDL_MessageBoxData

§

impl !Send for devela::_dep::sdl2::sys::SDL_Palette

§

impl !Send for devela::_dep::sdl2::sys::SDL_PixelFormat

§

impl !Send for SDL_RWops

§

impl !Send for SDL_RWops__bindgen_ty_1__bindgen_ty_1

§

impl !Send for SDL_RWops__bindgen_ty_1__bindgen_ty_2

§

impl !Send for SDL_RendererInfo

§

impl !Send for devela::_dep::sdl2::sys::SDL_Surface

§

impl !Send for SDL_SysWMEvent

§

impl !Send for SDL_SysWMinfo

§

impl !Send for SDL_SysWMinfo__bindgen_ty_1__bindgen_ty_1

§

impl !Send for SDL_SysWMinfo__bindgen_ty_1__bindgen_ty_2

§

impl !Send for SDL_SysWMmsg

§

impl !Send for SDL_SysWMmsg__bindgen_ty_1__bindgen_ty_1

§

impl !Send for SDL_TextEditingExtEvent

§

impl !Send for devela::_dep::sdl2::sys::SDL_UserEvent

§

impl !Send for devela::_dep::sdl2::sys::SDL_VirtualJoystickDesc

§

impl !Send for devela::_dep::sdl2::sys::SDL_hid_device_info

§

impl !Send for devela::_dep::sdl2::sys::Screen

§

impl !Send for ScreenFormat

§

impl !Send for devela::_dep::sdl2::sys::Visual

§

impl !Send for XAnyEvent

§

impl !Send for XButtonEvent

§

impl !Send for XCirculateEvent

§

impl !Send for XCirculateRequestEvent

§

impl !Send for XClientMessageEvent

§

impl !Send for XColormapEvent

§

impl !Send for XConfigureEvent

§

impl !Send for XConfigureRequestEvent

§

impl !Send for XCreateWindowEvent

§

impl !Send for XCrossingEvent

§

impl !Send for XDestroyWindowEvent

§

impl !Send for XErrorEvent

§

impl !Send for XExposeEvent

§

impl !Send for XFocusChangeEvent

§

impl !Send for XFontStruct

§

impl !Send for XGenericEvent

§

impl !Send for XGenericEventCookie

§

impl !Send for XGraphicsExposeEvent

§

impl !Send for XGravityEvent

§

impl !Send for XHostAddress

§

impl !Send for XICCallback

§

impl !Send for XIMCallback

§

impl !Send for XIMStyles

§

impl !Send for XIMValuesList

§

impl !Send for XKeyEvent

§

impl !Send for XKeymapEvent

§

impl !Send for XMapEvent

§

impl !Send for XMapRequestEvent

§

impl !Send for XMappingEvent

§

impl !Send for XModifierKeymap

§

impl !Send for XMotionEvent

§

impl !Send for XNoExposeEvent

§

impl !Send for XOMCharSetList

§

impl !Send for XOMFontInfo

§

impl !Send for XOMOrientation

§

impl !Send for XPropertyEvent

§

impl !Send for XReparentEvent

§

impl !Send for XResizeRequestEvent

§

impl !Send for XSelectionClearEvent

§

impl !Send for XSelectionEvent

§

impl !Send for XSelectionRequestEvent

§

impl !Send for XServerInterpretedAddress

§

impl !Send for XTextItem16

§

impl !Send for XTextItem

§

impl !Send for XUnmapEvent

§

impl !Send for XVisibilityEvent

§

impl !Send for XWindowAttributes

§

impl !Send for XmbTextItem

§

impl !Send for XwcTextItem

§

impl !Send for _XExtData

§

impl !Send for _XIMHotKeyTriggers

§

impl !Send for _XIMPreeditDrawCallbackStruct

§

impl !Send for _XIMStatusDrawCallbackStruct

§

impl !Send for _XIMStringConversionCallbackStruct

§

impl !Send for _XIMStringConversionText

§

impl !Send for _XIMText

§

impl !Send for _XImage

§

impl !Send for __pthread_internal_list

§

impl !Send for __pthread_internal_slist

§

impl !Send for __pthread_mutex_s

§

impl !Send for __va_list_tag

§

impl !Send for _bindgen_ty_1

§

impl !Send for random_data

§

impl !Send for devela::_dep::sdl2::video::GLContext

§

impl !Send for devela::_dep::sdl2::video::Window

§

impl !Send for devela::_dep::sdl2::video::WindowBuilder

§

impl !Send for devela::_dep::sdl2::video::WindowContext

§

impl !Send for devela::_dep::sdl3::audio::AudioDevice

§

impl !Send for devela::_dep::sdl3::audio::AudioSpecWAV

§

impl !Send for AudioStream

§

impl !Send for devela::_dep::sdl3::clipboard::ClipboardUtil

§

impl !Send for devela::_dep::sdl3::gamepad::Gamepad

§

impl !Send for Buffer

§

impl !Send for BufferBinding

§

impl !Send for BufferRegion

§

impl !Send for ColorTargetInfo

§

impl !Send for CommandBuffer

§

impl !Send for ComputePass

§

impl !Send for ComputePipeline

§

impl !Send for CopyPass

§

impl !Send for DepthStencilTargetInfo

§

impl !Send for devela::_dep::sdl3::gpu::Device

§

impl !Send for GraphicsPipeline

§

impl !Send for GraphicsPipelineTargetInfo

§

impl !Send for devela::_dep::sdl3::gpu::RenderPass

§

impl !Send for Sampler

§

impl !Send for Shader

§

impl !Send for TextureRegion

§

impl !Send for TextureSamplerBinding

§

impl !Send for TextureTransferInfo

§

impl !Send for TransferBuffer

§

impl !Send for TransferBufferLocation

§

impl !Send for VertexInputState

§

impl !Send for devela::_dep::sdl3::haptic::Haptic

§

impl !Send for devela::_dep::sdl3::joystick::Joystick

§

impl !Send for devela::_dep::sdl3::keyboard::KeyboardUtil

§

impl !Send for devela::_dep::sdl3::keyboard::TextInputUtil

§

impl !Send for devela::_dep::sdl3::mouse::Cursor

§

impl !Send for devela::_dep::sdl3::mouse::MouseUtil

§

impl !Send for devela::_dep::sdl3::pixels::Palette

§

impl !Send for devela::_dep::sdl3::AudioSubsystem

§

impl !Send for CameraSubsystem

§

impl !Send for devela::_dep::sdl3::EventPump

§

impl !Send for devela::_dep::sdl3::EventSubsystem

§

impl !Send for GamepadSubsystem

§

impl !Send for devela::_dep::sdl3::HapticSubsystem

§

impl !Send for devela::_dep::sdl3::JoystickSubsystem

§

impl !Send for devela::_dep::sdl3::Sdl

§

impl !Send for devela::_dep::sdl3::SensorSubsystem

§

impl !Send for devela::_dep::sdl3::VideoSubsystem

§

impl !Send for devela::_dep::sdl3::sys::assert::SDL_AssertData

§

impl !Send for SDL_AsyncIOOutcome

§

impl !Send for SDL_DialogFileFilter

§

impl !Send for SDL_ClipboardEvent

§

impl !Send for devela::_dep::sdl3::sys::events::SDL_DropEvent

§

impl !Send for SDL_TextEditingCandidatesEvent

§

impl !Send for devela::_dep::sdl3::sys::events::SDL_TextEditingEvent

§

impl !Send for devela::_dep::sdl3::sys::events::SDL_TextInputEvent

§

impl !Send for devela::_dep::sdl3::sys::events::SDL_UserEvent

§

impl !Send for SDL_GPUBlitInfo

§

impl !Send for SDL_GPUBlitRegion

§

impl !Send for SDL_GPUBufferBinding

§

impl !Send for SDL_GPUBufferLocation

§

impl !Send for SDL_GPUBufferRegion

§

impl !Send for SDL_GPUColorTargetInfo

§

impl !Send for SDL_GPUComputePipelineCreateInfo

§

impl !Send for SDL_GPUDepthStencilTargetInfo

§

impl !Send for SDL_GPUGraphicsPipelineCreateInfo

§

impl !Send for SDL_GPUGraphicsPipelineTargetInfo

§

impl !Send for SDL_GPUShaderCreateInfo

§

impl !Send for SDL_GPUStorageBufferReadWriteBinding

§

impl !Send for SDL_GPUStorageTextureReadWriteBinding

§

impl !Send for SDL_GPUTextureLocation

§

impl !Send for SDL_GPUTextureRegion

§

impl !Send for SDL_GPUTextureSamplerBinding

§

impl !Send for SDL_GPUTextureTransferInfo

§

impl !Send for SDL_GPUTransferBufferLocation

§

impl !Send for SDL_GPUVertexInputState

§

impl !Send for devela::_dep::sdl3::sys::haptic::SDL_HapticCustom

§

impl !Send for devela::_dep::sdl3::sys::hidapi::SDL_hid_device_info

§

impl !Send for devela::_dep::sdl3::sys::joystick::SDL_VirtualJoystickDesc

§

impl !Send for devela::_dep::sdl3::sys::locale::SDL_Locale

§

impl !Send for devela::_dep::sdl3::sys::messagebox::SDL_MessageBoxButtonData

§

impl !Send for devela::_dep::sdl3::sys::messagebox::SDL_MessageBoxData

§

impl !Send for SDL_InitState

§

impl !Send for devela::_dep::sdl3::sys::pixels::SDL_Palette

§

impl !Send for devela::_dep::sdl3::sys::surface::SDL_Surface

§

impl !Send for devela::_dep::sdl3::sys::video::SDL_DisplayMode

§

impl !Send for devela::_dep::sdl3::timer::Timer

§

impl !Send for devela::_dep::sdl3::video::DisplayMode

§

impl !Send for devela::_dep::sdl3::video::GLContext

§

impl !Send for PopupWindowBuilder

§

impl !Send for devela::_dep::sdl3::video::Window

§

impl !Send for devela::_dep::sdl3::video::WindowBuilder

§

impl !Send for devela::_dep::sdl3::video::WindowContext

§

impl !Send for LocalEnterGuard

§

impl !Send for LocalSet

§

impl !Send for EnteredSpan

§

impl !Send for JsError

§

impl !Send for JsValue

§

impl !Send for FatPtr

§

impl !Send for Vars

§

impl !Send for VarsOs

§

impl !Send for MiniquadPixels

§

impl !Send for RawWaker

§

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 __c_anonymous_ifc_ifcu

§

impl !Send for __c_anonymous_ifr_ifru

§

impl !Send for iwreq_data

§

impl !Send for devela::_dep::sdl2::sys::SDL_Event

§

impl !Send for devela::_dep::sdl2::sys::SDL_HapticEffect

§

impl !Send for SDL_RWops__bindgen_ty_1

§

impl !Send for SDL_SysWMinfo__bindgen_ty_1

§

impl !Send for SDL_SysWMmsg__bindgen_ty_1

§

impl !Send for XEDataObject

§

impl !Send for _XEvent

§

impl !Send for _XIMStatusDrawCallbackStruct__bindgen_ty_1

§

impl !Send for _XIMStringConversionText__bindgen_ty_1

§

impl !Send for _XIMText__bindgen_ty_1

§

impl !Send for devela::_dep::sdl2::sys::pthread_mutex_t

§

impl !Send for devela::_dep::sdl3::sys::events::SDL_Event

§

impl !Send for devela::_dep::sdl3::sys::haptic::SDL_HapticEffect

§

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 FromBytesWithNulError

§

impl Send for DebugAsHex

§

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

§

impl Send for BasicBlock

§

impl Send for UnwindTerminateReason

§

impl Send for Ipv6MulticastScope

§

impl Send for OneSidedRangeBound

§

impl Send for GetDisjointMutError

§

impl Send for SearchStep

§

impl Send for TryReserveErrorKind

§

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

§

impl Send for AncillaryError

§

impl Send for BacktraceStyle

§

impl Send for devela::_dep::_std::sync::mpmc::RecvTimeoutError

§

impl Send for devela::_dep::_std::sync::mpmc::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 ClipboardContent

§

impl Send for ClipboardEvent

§

impl Send for ContrastMode

§

impl Send for devela::_dep::fltk::app::MouseButton

§

impl Send for MouseWheel

§

impl Send for devela::_dep::fltk::app::Option

§

impl Send for devela::_dep::fltk::app::Scheme

§

impl Send for BrowserScrollbar

§

impl Send for BrowserType

§

impl Send for devela::_dep::fltk::browser::FileType

§

impl Send for ButtonType

§

impl Send for BeepType

§

impl Send for devela::_dep::fltk::dialog::ColorMode

§

impl Send for FileDialogAction

§

impl Send for FileDialogType

§

impl Send for CallbackReason

§

impl Send for ColorDepth

§

impl Send for devela::_dep::fltk::enums::Cursor

§

impl Send for FrameType

§

impl Send for LabelType

§

impl Send for FlexType

§

impl Send for PackType

§

impl Send for ScrollType

§

impl Send for TabsOverflow

§

impl Send for RgbScaling

§

impl Send for InputType

§

impl Send for MenuButtonType

§

impl Send for WindowMenuStyle

§

impl Send for ChartType

§

impl Send for ClockType

§

impl Send for OutputType

§

impl Send for FltkErrorKind

§

impl Send for TableContext

§

impl Send for TableResizeFlag

§

impl Send for TableRowSelectFlag

§

impl Send for TableRowSelectMode

§

impl Send for XtermColor

§

impl Send for devela::_dep::fltk::text::Cursor

§

impl Send for DragType

§

impl Send for TextAttr

§

impl Send for WrapMode

§

impl Send for TreeConnectorStyle

§

impl Send for TreeItemDrawMode

§

impl Send for TreeItemReselectMode

§

impl Send for TreeItemSelect

§

impl Send for TreeReason

§

impl Send for TreeSelect

§

impl Send for TreeSort

§

impl Send for CounterType

§

impl Send for DialType

§

impl Send for ScrollbarType

§

impl Send for SliderType

§

impl Send for WindowType

§

impl Send for devela::_dep::flume::RecvError

§

impl Send for devela::_dep::flume::RecvTimeoutError

§

impl Send for devela::_dep::flume::TryRecvError

§

impl Send for CoordinateSystem

§

impl Send for HorizontalAlign

§

impl Send for VerticalAlign

§

impl Send for WrapStyle

§

impl Send for devela::_dep::gilrs::Axis

§

impl Send for devela::_dep::gilrs::Button

§

impl Send for devela::_dep::gilrs::Error

§

impl Send for devela::_dep::gilrs::EventType

§

impl Send for MappingError

§

impl Send for MappingSource

§

impl Send for devela::_dep::gilrs::PowerInfo

§

impl Send for AxisOrBtn

§

impl Send for BaseEffectType

§

impl Send for DistanceModel

§

impl Send for DistanceModelError

§

impl Send for devela::_dep::gilrs::ff::Error

§

impl Send for devela::_dep::gilrs::ff::Repeat

§

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

§

impl Send for PixelDensityUnit

§

impl Send for CompressionType

§

impl Send for devela::_dep::image::codecs::png::FilterType

§

impl Send for ArbitraryTuplType

§

impl Send for PnmSubtype

§

impl Send for SampleEncoding

§

impl Send for ColorType

§

impl Send for DynamicImage

§

impl Send for ExtendedColorType

§

impl Send for devela::_dep::image::ImageError

§

impl Send for ImageFormat

§

impl Send for ImageFormatHint

§

impl Send for LimitErrorKind

§

impl Send for ParameterErrorKind

§

impl Send for UnsupportedErrorKind

§

impl Send for devela::_dep::image::flat::Error

§

impl Send for NormalForm

§

impl Send for devela::_dep::image::imageops::FilterType

§

impl Send for devela::_dep::image::metadata::Orientation

§

impl Send for devela::_dep::itertools::Position

§

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 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 devela::_dep::miniquad::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 devela::_dep::miniquad::PrimitiveType

§

impl Send for ShaderError

§

impl Send for ShaderType

§

impl Send for devela::_dep::miniquad::StencilOp

§

impl Send for devela::_dep::miniquad::TextureAccess

§

impl Send for devela::_dep::miniquad::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 devela::_dep::miniquad::log::Level

§

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 StreamTag

§

impl Send for Hasher

§

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 devela::_dep::pyo3::pyclass::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 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 devela::_dep::rustix::net::sockopt::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::sdl2::audio::AudioFormat

§

impl Send for AudioStatus

§

impl Send for devela::_dep::sdl2::controller::AddMappingError

§

impl Send for devela::_dep::sdl2::controller::Axis

§

impl Send for devela::_dep::sdl2::controller::Button

§

impl Send for devela::_dep::sdl2::controller::MappingStatus

§

impl Send for devela::_dep::sdl2::Error

§

impl Send for devela::_dep::sdl2::IntegerOrSdlError

§

impl Send for devela::_dep::sdl2::event::DisplayEvent

§

impl Send for devela::_dep::sdl2::event::EventType

§

impl Send for devela::_dep::sdl2::event::WindowEvent

§

impl Send for devela::_dep::sdl2::filesystem::PrefPathError

§

impl Send for devela::_dep::sdl2::hint::Hint

§

impl Send for devela::_dep::sdl2::joystick::HatState

§

impl Send for devela::_dep::sdl2::joystick::PowerLevel

§

impl Send for devela::_dep::sdl2::keyboard::Scancode

§

impl Send for DIR

§

impl Send for FILE

§

impl Send for fpos64_t

§

impl Send for fpos_t

§

impl Send for timezone

§

impl Send for tpacket_versions

§

impl Send for devela::_dep::sdl2::log::Category

§

impl Send for devela::_dep::sdl2::log::Priority

§

impl Send for devela::_dep::sdl2::messagebox::ShowMessageError

§

impl Send for Fading

§

impl Send for MusicType

§

impl Send for devela::_dep::sdl2::mouse::MouseButton

§

impl Send for devela::_dep::sdl2::mouse::MouseWheelDirection

§

impl Send for devela::_dep::sdl2::mouse::SystemCursor

§

impl Send for PixelFormatEnum

§

impl Send for devela::_dep::sdl2::render::BlendMode

§

impl Send for devela::_dep::sdl2::render::TargetRenderError

§

impl Send for devela::_dep::sdl2::render::TextureAccess

§

impl Send for devela::_dep::sdl2::render::TextureValueError

§

impl Send for devela::_dep::sdl2::render::UpdateTextureError

§

impl Send for devela::_dep::sdl2::render::UpdateTextureYUVError

§

impl Send for devela::_dep::sdl2::sys::SDL_ArrayOrder

§

impl Send for devela::_dep::sdl2::sys::SDL_AssertState

§

impl Send for SDL_AudioStatus

§

impl Send for devela::_dep::sdl2::sys::SDL_BitmapOrder

§

impl Send for devela::_dep::sdl2::sys::SDL_BlendFactor

§

impl Send for SDL_BlendMode

§

impl Send for devela::_dep::sdl2::sys::SDL_BlendOperation

§

impl Send for SDL_DUMMY_ENUM

§

impl Send for SDL_DisplayEventID

§

impl Send for devela::_dep::sdl2::sys::SDL_DisplayOrientation

§

impl Send for devela::_dep::sdl2::sys::SDL_EventType

§

impl Send for devela::_dep::sdl2::sys::SDL_FlashOperation

§

impl Send for SDL_GLContextResetNotification

§

impl Send for SDL_GLattr

§

impl Send for SDL_GLcontextFlag

§

impl Send for SDL_GLcontextReleaseFlag

§

impl Send for SDL_GLprofile

§

impl Send for SDL_GameControllerAxis

§

impl Send for SDL_GameControllerBindType

§

impl Send for SDL_GameControllerButton

§

impl Send for SDL_GameControllerType

§

impl Send for devela::_dep::sdl2::sys::SDL_HintPriority

§

impl Send for devela::_dep::sdl2::sys::SDL_HitTestResult

§

impl Send for SDL_JoystickPowerLevel

§

impl Send for devela::_dep::sdl2::sys::SDL_JoystickType

§

impl Send for SDL_KeyCode

§

impl Send for SDL_Keymod

§

impl Send for devela::_dep::sdl2::sys::SDL_LogCategory

§

impl Send for devela::_dep::sdl2::sys::SDL_LogPriority

§

impl Send for SDL_MessageBoxButtonFlags

§

impl Send for devela::_dep::sdl2::sys::SDL_MessageBoxColorType

§

impl Send for SDL_MessageBoxFlags

§

impl Send for devela::_dep::sdl2::sys::SDL_MouseWheelDirection

§

impl Send for devela::_dep::sdl2::sys::SDL_PackedLayout

§

impl Send for devela::_dep::sdl2::sys::SDL_PackedOrder

§

impl Send for SDL_PixelFormatEnum

§

impl Send for devela::_dep::sdl2::sys::SDL_PixelType

§

impl Send for devela::_dep::sdl2::sys::SDL_PowerState

§

impl Send for SDL_RendererFlags

§

impl Send for SDL_RendererFlip

§

impl Send for SDL_SYSWM_TYPE

§

impl Send for devela::_dep::sdl2::sys::SDL_ScaleMode

§

impl Send for devela::_dep::sdl2::sys::SDL_Scancode

§

impl Send for devela::_dep::sdl2::sys::SDL_SensorType

§

impl Send for devela::_dep::sdl2::sys::SDL_SystemCursor

§

impl Send for devela::_dep::sdl2::sys::SDL_TextureAccess

§

impl Send for SDL_TextureModulate

§

impl Send for devela::_dep::sdl2::sys::SDL_ThreadPriority

§

impl Send for devela::_dep::sdl2::sys::SDL_TouchDeviceType

§

impl Send for SDL_WindowEventID

§

impl Send for SDL_WindowFlags

§

impl Send for SDL_YUV_CONVERSION_MODE

§

impl Send for SDL_bool

§

impl Send for SDL_errorcode

§

impl Send for SDL_eventaction

§

impl Send for WindowShapeMode

§

impl Send for XIMCaretDirection

§

impl Send for XIMCaretStyle

§

impl Send for XIMStatusDataType

§

impl Send for XOrientation

§

impl Send for devela::_dep::sdl2::ttf::FontError

§

impl Send for Hinting

§

impl Send for devela::_dep::sdl2::ttf::InitError

§

impl Send for devela::_dep::sdl2::url::OpenUrlError

§

impl Send for devela::_dep::sdl2::video::FlashOperation

§

impl Send for devela::_dep::sdl2::video::FullscreenType

§

impl Send for devela::_dep::sdl2::video::GLProfile

§

impl Send for devela::_dep::sdl2::video::Orientation

§

impl Send for devela::_dep::sdl2::video::SwapInterval

§

impl Send for devela::_dep::sdl2::video::WindowBuildError

§

impl Send for devela::_dep::sdl2::video::WindowPos

§

impl Send for AudioDeviceID

§

impl Send for devela::_dep::sdl3::audio::AudioFormat

§

impl Send for DialogError

§

impl Send for devela::_dep::sdl3::IntegerOrSdlError

§

impl Send for devela::_dep::sdl3::event::DisplayEvent

§

impl Send for devela::_dep::sdl3::event::EventType

§

impl Send for devela::_dep::sdl3::event::WindowEvent

§

impl Send for FileSystemError

§

impl Send for devela::_dep::sdl3::filesystem::PrefPathError

§

impl Send for devela::_dep::sdl3::gamepad::AddMappingError

§

impl Send for devela::_dep::sdl3::gamepad::Axis

§

impl Send for devela::_dep::sdl3::gamepad::Button

§

impl Send for devela::_dep::sdl3::gamepad::MappingStatus

§

impl Send for devela::_dep::sdl3::gpu::BlendFactor

§

impl Send for BlendOp

§

impl Send for BufferUsageFlags

§

impl Send for ColorComponentFlags

§

impl Send for devela::_dep::sdl3::gpu::CompareOp

§

impl Send for CullMode

§

impl Send for FillMode

§

impl Send for devela::_dep::sdl3::gpu::Filter

§

impl Send for FrontFace

§

impl Send for IndexElementSize

§

impl Send for LoadOp

§

impl Send for devela::_dep::sdl3::gpu::PrimitiveType

§

impl Send for SampleCount

§

impl Send for SamplerAddressMode

§

impl Send for SamplerMipmapMode

§

impl Send for ShaderFormat

§

impl Send for ShaderStage

§

impl Send for devela::_dep::sdl3::gpu::StencilOp

§

impl Send for StoreOp

§

impl Send for devela::_dep::sdl3::gpu::TextureFormat

§

impl Send for TextureType

§

impl Send for TextureUsage

§

impl Send for TransferBufferUsage

§

impl Send for VertexElementFormat

§

impl Send for VertexInputRate

§

impl Send for devela::_dep::sdl3::hint::Hint

§

impl Send for devela::_dep::sdl3::joystick::HatState

§

impl Send for devela::_dep::sdl3::joystick::PowerLevel

§

impl Send for devela::_dep::sdl3::keyboard::Keycode

§

impl Send for devela::_dep::sdl3::keyboard::Scancode

§

impl Send for devela::_dep::sdl3::log::Category

§

impl Send for devela::_dep::sdl3::log::Priority

§

impl Send for devela::_dep::sdl3::messagebox::ShowMessageError

§

impl Send for devela::_dep::sdl3::mouse::MouseButton

§

impl Send for devela::_dep::sdl3::mouse::MouseWheelDirection

§

impl Send for devela::_dep::sdl3::mouse::SystemCursor

§

impl Send for PropertiesError

§

impl Send for devela::_dep::sdl3::render::BlendMode

§

impl Send for ClippingRect

§

impl Send for ScaleMode

§

impl Send for devela::_dep::sdl3::render::TargetRenderError

§

impl Send for devela::_dep::sdl3::render::TextureAccess

§

impl Send for devela::_dep::sdl3::render::TextureValueError

§

impl Send for devela::_dep::sdl3::render::UpdateTextureError

§

impl Send for devela::_dep::sdl3::render::UpdateTextureYUVError

§

impl Send for devela::_dep::sdl3::sys::ffi::VaList

§

impl Send for devela::_dep::sdl3::url::OpenUrlError

§

impl Send for devela::_dep::sdl3::video::FlashOperation

§

impl Send for devela::_dep::sdl3::video::FullscreenType

§

impl Send for devela::_dep::sdl3::video::GLProfile

§

impl Send for devela::_dep::sdl3::video::Orientation

§

impl Send for devela::_dep::sdl3::video::SwapInterval

§

impl Send for SystemTheme

§

impl Send for devela::_dep::sdl3::video::WindowBuildError

§

impl Send for devela::_dep::sdl3::video::WindowPos

§

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 devela::_dep::symphonia::core::meta::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 RuntimeFlavor

§

impl Send for devela::_dep::tokio::sync::broadcast::error::RecvError

§

impl Send for devela::_dep::tokio::sync::broadcast::error::TryRecvError

§

impl Send for TryAcquireError

§

impl Send for devela::_dep::tokio::sync::mpsc::error::TryRecvError

§

impl Send for devela::_dep::tokio::sync::oneshot::error::TryRecvError

§

impl Send for Item

§

impl Send for devela::_dep::toml_edit::Offset

§

impl Send for devela::_dep::toml_edit::Value

§

impl Send for devela::_dep::toml_edit::ser::Error

§

impl Send for GraphemeIncomplete

§

impl Send for AutoHeaderValue

§

impl Send for IpFamily

§

impl Send for RedirectAuthHeaders

§

impl Send for devela::_dep::ureq::Error

§

impl Send for devela::_dep::ureq::Timeout

§

impl Send for devela::_dep::ureq::unversioned::transport::time::Duration

§

impl Send for devela::_dep::ureq::unversioned::transport::time::Instant

§

impl Send for Endianness

§

impl Send for Needed

§

impl Send for StrContext

§

impl Send for StrContextValue

§

impl Send for CompareResult

§

impl Send for Infallible

§

impl Send for FpCategory

§

impl Send for NumError

§

impl Send for devela::num::Sign

§

impl Send for UnitBi

§

impl Send for UnitSi

§

impl Send for devela::text::AsciiChar

§

impl Send for InvalidText

§

impl Send for TextError

§

impl Send for UiError

§

impl Send for AllError

§

impl Send for AllErrorKind

§

impl Send for AngleDirection

§

impl Send for AngleKind

§

impl Send for devela::all::AtomicOrdering

§

impl Send for AudioError

§

impl Send for BacktraceStatus

§

impl Send for ColorError

§

impl Send for CompressionMode

§

impl Send for DataError

§

impl Send for DataNotEnough

§

impl Send for Dither

§

impl Send for DrawError

§

impl Send for EncodingMode

§

impl Send for devela::all::FmtAlignment

§

impl Send for devela::all::FontError

§

impl Send for devela::all::ImageError

§

impl Send for ErrorKind

§

impl Send for IpAddr

§

impl Send for JsEvent

§

impl Send for JsPermission

§

impl Send for JsPermissionState

§

impl Send for devela::all::LayoutError

§

impl Send for devela::all::LogLevel

§

impl Send for devela::all::LogLevelFilter

§

impl Send for MediaError

§

impl Send for MidiError

§

impl Send for MismatchedBounds

§

impl Send for Month

§

impl Send for NotAvailable

§

impl Send for devela::all::Ordering

§

impl Send for IntErrorKind

§

impl Send for PartialSpace

§

impl Send for devela::all::PixelFormat

§

impl Send for SixelError

§

impl Send for SixelMean

§

impl Send for SixelQuality

§

impl Send for SixelSplit

§

impl Send for devela::all::SocketAddr

§

impl Send for SpinStrategy

§

impl Send for devela::all::TcpShutdown

§

impl Send for TimeError

§

impl Send for VarError

§

impl Send for WaveletUnitRole

§

impl Send for devela::all::Weekday

§

impl Send for c_void

§

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 ByteStr

§

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 FormattingOptions

§

impl Send for SipHasher

§

impl Send for ReturnToArg

§

impl Send for UnwindActionArg

§

impl Send for Assume

§

impl Send for devela::_core::ptr::Alignment

§

impl Send for ParseBoolError

§

impl Send for devela::_core::str::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 ByteString

§

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 BacktraceFrame

§

impl Send for DefaultHasher

§

impl Send for PipeReader

§

impl Send for PipeWriter

§

impl Send for WriterPanicked

§

impl Send for IntoIncoming

§

impl Send for PidFd

§

impl Send for devela::_dep::_std::os::linux::raw::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 ExitStatusError

§

impl Send for DefaultRandomSource

§

impl Send for devela::_dep::_std::sync::mpmc::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 FileAccess

§

impl Send for Root

§

impl Send for App

§

impl Send for devela::_dep::fltk::app::Screen

§

impl Send for FileChooserType

§

impl Send for FileDialogOptions

§

impl Send for LineStyle

§

impl Send for Align

§

impl Send for CallbackTrigger

§

impl Send for devela::_dep::fltk::enums::Color

§

impl Send for Damage

§

impl Send for devela::_dep::fltk::enums::Event

§

impl Send for devela::_dep::fltk::enums::Font

§

impl Send for devela::_dep::fltk::enums::Key

§

impl Send for devela::_dep::fltk::enums::Mode

§

impl Send for Shortcut

§

impl Send for Column

§

impl Send for GridAlign

§

impl Send for GridRange

§

impl Send for HGrid

§

impl Send for Row

§

impl Send for VGrid

§

impl Send for AnimGifImageFlags

§

impl Send for IconDirEntry

§

impl Send for MacAppMenu

§

impl Send for MenuFlag

§

impl Send for Tooltip

§

impl Send for Attrib

§

impl Send for CharFlags

§

impl Send for OutFlags

§

impl Send for RedrawStyle

§

impl Send for ScrollbarStyle

§

impl Send for StyleTableEntry

§

impl Send for StyleTableEntryExt

§

impl Send for AndroidWindow

§

impl Send for CharacterData

§

impl Send for GlyphRasterConfig

§

impl Send for LayoutSettings

§

impl Send for LinePosition

§

impl Send for devela::_dep::fontdue::Font

§

impl Send for FontSettings

§

impl Send for LineMetrics

§

impl Send for Metrics

§

impl Send for OutlineBounds

§

impl Send for Jitter

§

impl Send for devela::_dep::gilrs::ev::filter::Repeat

§

impl Send for AxisData

§

impl Send for devela::_dep::gilrs::ev::state::ButtonData

§

impl Send for GamepadState

§

impl Send for Code

§

impl Send for BaseEffect

§

impl Send for Effect

§

impl Send for EffectBuilder

§

impl Send for Envelope

§

impl Send for Replay

§

impl Send for Ticks

§

impl Send for devela::_dep::gilrs::Event

§

impl Send for GamepadId

§

impl Send for Gilrs

§

impl Send for GilrsBuilder

§

impl Send for MappingData

§

impl Send for PixelDensity

§

impl Send for ArbitraryHeader

§

impl Send for BitmapHeader

§

impl Send for GraymapHeader

§

impl Send for PixmapHeader

§

impl Send for PnmHeader

§

impl Send for DecodingError

§

impl Send for EncodingError

§

impl Send for LimitError

§

impl Send for ParameterError

§

impl Send for UnsupportedError

§

impl Send for SampleLayout

§

impl Send for BiLevel

§

impl Send for devela::_dep::image::math::Rect

§

impl Send for devela::_dep::image::Delay

§

impl Send for devela::_dep::image::Frame

§

impl Send for LimitSupport

§

impl Send for Limits

§

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 SpanFieldwise

§

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 devela::_dep::jiff::tz::Offset

§

impl Send for OffsetArithmetic

§

impl Send for OffsetRound

§

impl Send for TimeZone

§

impl Send for TimeZoneDatabase

§

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 devela::_dep::kira::sound::Region

§

impl Send for Capacities

§

impl Send for Decibels

§

impl Send for devela::_dep::kira::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 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 devela::_dep::midir::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 devela::_dep::miniquad::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 devela::_dep::miniquad::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 devela::_dep::nc::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 devela::_dep::nc::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 devela::_dep::nc::pthread_barrierattr_t

§

impl Send for devela::_dep::nc::pthread_condattr_t

§

impl Send for devela::_dep::nc::pthread_mutexattr_t

§

impl Send for devela::_dep::nc::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 devela::_dep::nc::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 devela::_dep::orion::aead::streaming::Nonce

§

impl Send for StreamOpener

§

impl Send for StreamSealer

§

impl Send for devela::_dep::orion::aead::SecretKey

§

impl Send for devela::_dep::orion::auth::Tag

§

impl Send for UnknownCryptoError

§

impl Send for devela::_dep::orion::hash::Digest

§

impl Send for devela::_dep::orion::hazardous::aead::chacha20poly1305::Nonce

§

impl Send for devela::_dep::orion::hazardous::aead::chacha20poly1305::SecretKey

§

impl Send for StreamXChaCha20Poly1305

§

impl Send for SharedKey

§

impl Send for devela::_dep::orion::hazardous::hash::blake2::blake2b::Blake2b

§

impl Send for devela::_dep::orion::hazardous::hash::sha2::sha256::Digest

§

impl Send for Sha256

§

impl Send for devela::_dep::orion::hazardous::hash::sha2::sha384::Digest

§

impl Send for Sha384

§

impl Send for devela::_dep::orion::hazardous::hash::sha2::sha512::Digest

§

impl Send for Sha512

§

impl Send for devela::_dep::orion::hazardous::hash::sha3::sha3_224::Digest

§

impl Send for Sha3_224

§

impl Send for devela::_dep::orion::hazardous::hash::sha3::sha3_256::Digest

§

impl Send for Sha3_256

§

impl Send for devela::_dep::orion::hazardous::hash::sha3::sha3_384::Digest

§

impl Send for Sha3_384

§

impl Send for devela::_dep::orion::hazardous::hash::sha3::sha3_512::Digest

§

impl Send for Sha3_512

§

impl Send for Shake128

§

impl Send for Shake256

§

impl Send for devela::_dep::orion::hazardous::kdf::pbkdf2::sha256::Password

§

impl Send for devela::_dep::orion::hazardous::kdf::pbkdf2::sha384::Password

§

impl Send for devela::_dep::orion::hazardous::kdf::pbkdf2::sha512::Password

§

impl Send for devela::_dep::orion::hazardous::kem::mlkem512::Ciphertext

§

impl Send for devela::_dep::orion::hazardous::kem::mlkem512::DecapsulationKey

§

impl Send for devela::_dep::orion::hazardous::kem::mlkem512::EncapsulationKey

§

impl Send for devela::_dep::orion::hazardous::kem::mlkem512::KeyPair

§

impl Send for MlKem512

§

impl Send for devela::_dep::orion::hazardous::kem::mlkem512::SharedSecret

§

impl Send for devela::_dep::orion::hazardous::kem::mlkem768::Ciphertext

§

impl Send for devela::_dep::orion::hazardous::kem::mlkem768::DecapsulationKey

§

impl Send for devela::_dep::orion::hazardous::kem::mlkem768::EncapsulationKey

§

impl Send for devela::_dep::orion::hazardous::kem::mlkem768::KeyPair

§

impl Send for MlKem768

§

impl Send for devela::_dep::orion::hazardous::kem::mlkem768::SharedSecret

§

impl Send for devela::_dep::orion::hazardous::kem::mlkem1024::Ciphertext

§

impl Send for devela::_dep::orion::hazardous::kem::mlkem1024::DecapsulationKey

§

impl Send for devela::_dep::orion::hazardous::kem::mlkem1024::EncapsulationKey

§

impl Send for devela::_dep::orion::hazardous::kem::mlkem1024::KeyPair

§

impl Send for MlKem1024

§

impl Send for devela::_dep::orion::hazardous::kem::mlkem1024::Seed

§

impl Send for devela::_dep::orion::hazardous::kem::mlkem1024::SharedSecret

§

impl Send for DhKem

§

impl Send for devela::_dep::orion::hazardous::kem::x25519_hkdf_sha256::SharedSecret

§

impl Send for devela::_dep::orion::hazardous::kem::xwing::Ciphertext

§

impl Send for devela::_dep::orion::hazardous::kem::xwing::DecapsulationKey

§

impl Send for devela::_dep::orion::hazardous::kem::xwing::EncapsulationKey

§

impl Send for devela::_dep::orion::hazardous::kem::xwing::KeyPair

§

impl Send for devela::_dep::orion::hazardous::kem::xwing::Seed

§

impl Send for devela::_dep::orion::hazardous::kem::xwing::SharedSecret

§

impl Send for XWing

§

impl Send for devela::_dep::orion::hazardous::mac::blake2b::Blake2b

§

impl Send for devela::_dep::orion::hazardous::mac::blake2b::SecretKey

§

impl Send for HmacSha256

§

impl Send for devela::_dep::orion::hazardous::mac::hmac::sha256::SecretKey

§

impl Send for devela::_dep::orion::hazardous::mac::hmac::sha256::Tag

§

impl Send for HmacSha384

§

impl Send for devela::_dep::orion::hazardous::mac::hmac::sha384::SecretKey

§

impl Send for devela::_dep::orion::hazardous::mac::hmac::sha384::Tag

§

impl Send for HmacSha512

§

impl Send for devela::_dep::orion::hazardous::mac::hmac::sha512::SecretKey

§

impl Send for devela::_dep::orion::hazardous::mac::hmac::sha512::Tag

§

impl Send for OneTimeKey

§

impl Send for Poly1305

§

impl Send for devela::_dep::orion::hazardous::mac::poly1305::Tag

§

impl Send for Salt

§

impl Send for EphemeralClientSession

§

impl Send for EphemeralServerSession

§

impl Send for PrivateKey

§

impl Send for PublicKey

§

impl Send for SessionKeys

§

impl Send for devela::_dep::orion::pwhash::Password

§

impl Send for PasswordHash

§

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 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 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 devela::_dep::rustix::fs::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 devela::_dep::rustix::io_uring::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 devela::_dep::sdl2::audio::AudioSpec

§

impl Send for AudioSpecDesired

§

impl Send for devela::_dep::sdl2::audio::DriverIterator

§

impl Send for devela::_dep::sdl2::event::EventSender

§

impl Send for devela::_dep::sdl2::image::InitFlag

§

impl Send for Sdl2ImageContext

§

impl Send for Guid

§

impl Send for devela::_dep::sdl2::keyboard::Keycode

§

impl Send for devela::_dep::sdl2::keyboard::Mod

§

impl Send for Elf32_Chdr

§

impl Send for Elf32_Ehdr

§

impl Send for Elf32_Phdr

§

impl Send for Elf32_Shdr

§

impl Send for Elf32_Sym

§

impl Send for Elf64_Chdr

§

impl Send for Elf64_Ehdr

§

impl Send for Elf64_Phdr

§

impl Send for Elf64_Shdr

§

impl Send for Elf64_Sym

§

impl Send for __c_anonymous__kernel_fsid_t

§

impl Send for __c_anonymous_elf32_rel

§

impl Send for __c_anonymous_elf32_rela

§

impl Send for __c_anonymous_elf64_rel

§

impl Send for __c_anonymous_elf64_rela

§

impl Send for __c_anonymous_ifru_map

§

impl Send for __c_anonymous_ptrace_syscall_info_entry

§

impl Send for __c_anonymous_ptrace_syscall_info_exit

§

impl Send for __c_anonymous_ptrace_syscall_info_seccomp

§

impl Send for __c_anonymous_sockaddr_can_j1939

§

impl Send for __c_anonymous_sockaddr_can_tp

§

impl Send for __exit_status

§

impl Send for __timeval

§

impl Send for _libc_fpstate

§

impl Send for _libc_fpxreg

§

impl Send for _libc_xmmreg

§

impl Send for af_alg_iv

§

impl Send for arpd_request

§

impl Send for arphdr

§

impl Send for arpreq

§

impl Send for arpreq_old

§

impl Send for can_filter

§

impl Send for can_frame

§

impl Send for canfd_frame

§

impl Send for canxl_frame

§

impl Send for clone_args

§

impl Send for cmsghdr

§

impl Send for devela::_dep::sdl2::libc::cpu_set_t

§

impl Send for dirent64

§

impl Send for dirent

§

impl Send for dqblk

§

impl Send for epoll_event

§

impl Send for epoll_params

§

impl Send for fanotify_event_info_error

§

impl Send for fanotify_event_info_fid

§

impl Send for fanotify_event_info_header

§

impl Send for fanotify_event_info_pidfd

§

impl Send for fanotify_event_metadata

§

impl Send for fanotify_response

§

impl Send for fanout_args

§

impl Send for devela::_dep::sdl2::libc::fd_set

§

impl Send for ff_condition_effect

§

impl Send for ff_constant_effect

§

impl Send for ff_effect

§

impl Send for ff_envelope

§

impl Send for ff_ramp_effect

§

impl Send for ff_replay

§

impl Send for ff_rumble_effect

§

impl Send for ff_trigger

§

impl Send for file_clone_range

§

impl Send for flock64

§

impl Send for flock

§

impl Send for devela::_dep::sdl2::libc::fsid_t

§

impl Send for genlmsghdr

§

impl Send for hwtstamp_config

§

impl Send for in6_addr

§

impl Send for in6_ifreq

§

impl Send for in6_pktinfo

§

impl Send for in6_rtmsg

§

impl Send for in_addr

§

impl Send for in_pktinfo

§

impl Send for inotify_event

§

impl Send for input_absinfo

§

impl Send for input_event

§

impl Send for input_id

§

impl Send for input_keymap_entry

§

impl Send for input_mask

§

impl Send for iocb

§

impl Send for ip_mreq

§

impl Send for ip_mreq_source

§

impl Send for ip_mreqn

§

impl Send for ipc_perm

§

impl Send for ipv6_mreq

§

impl Send for itimerspec

§

impl Send for itimerval

§

impl Send for iw_discarded

§

impl Send for iw_encode_ext

§

impl Send for iw_freq

§

impl Send for iw_michaelmicfailure

§

impl Send for iw_missed

§

impl Send for iw_mlme

§

impl Send for iw_param

§

impl Send for iw_pmkid_cand

§

impl Send for iw_pmksa

§

impl Send for iw_priv_args

§

impl Send for iw_quality

§

impl Send for iw_range

§

impl Send for iw_scan_req

§

impl Send for iw_statistics

§

impl Send for iw_thrspy

§

impl Send for j1939_filter

§

impl Send for linger

§

impl Send for mallinfo2

§

impl Send for mallinfo

§

impl Send for devela::_dep::sdl2::libc::max_align_t

§

impl Send for mount_attr

§

impl Send for mq_attr

§

impl Send for msginfo

§

impl Send for msqid_ds

§

impl Send for nl_mmap_hdr

§

impl Send for nl_mmap_req

§

impl Send for nl_pktinfo

§

impl Send for nlattr

§

impl Send for nlmsgerr

§

impl Send for nlmsghdr

§

impl Send for ntptimeval

§

impl Send for devela::_dep::sdl2::libc::open_how

§

impl Send for packet_mreq

§

impl Send for pollfd

§

impl Send for posix_spawnattr_t

§

impl Send for devela::_dep::sdl2::libc::pthread_attr_t

§

impl Send for devela::_dep::sdl2::libc::pthread_barrier_t

§

impl Send for devela::_dep::sdl2::libc::pthread_barrierattr_t

§

impl Send for devela::_dep::sdl2::libc::pthread_cond_t

§

impl Send for devela::_dep::sdl2::libc::pthread_condattr_t

§

impl Send for devela::_dep::sdl2::libc::pthread_mutex_t

§

impl Send for devela::_dep::sdl2::libc::pthread_mutexattr_t

§

impl Send for devela::_dep::sdl2::libc::pthread_rwlock_t

§

impl Send for devela::_dep::sdl2::libc::pthread_rwlockattr_t

§

impl Send for ptp_clock_caps

§

impl Send for ptp_clock_time

§

impl Send for ptp_extts_event

§

impl Send for ptp_extts_request

§

impl Send for ptp_perout_request

§

impl Send for ptp_pin_desc

§

impl Send for ptp_sys_offset

§

impl Send for ptp_sys_offset_extended

§

impl Send for ptp_sys_offset_precise

§

impl Send for ptrace_peeksiginfo_args

§

impl Send for ptrace_rseq_configuration

§

impl Send for ptrace_syscall_info

§

impl Send for regmatch_t

§

impl Send for rlimit64

§

impl Send for rlimit

§

impl Send for rusage

§

impl Send for sched_attr

§

impl Send for sched_param

§

impl Send for sctp_authinfo

§

impl Send for sctp_initmsg

§

impl Send for sctp_nxtinfo

§

impl Send for sctp_prinfo

§

impl Send for sctp_rcvinfo

§

impl Send for sctp_sndinfo

§

impl Send for sctp_sndrcvinfo

§

impl Send for seccomp_data

§

impl Send for seccomp_notif

§

impl Send for seccomp_notif_addfd

§

impl Send for seccomp_notif_resp

§

impl Send for seccomp_notif_sizes

§

impl Send for sem_t

§

impl Send for sembuf

§

impl Send for semid_ds

§

impl Send for seminfo

§

impl Send for shmid_ds

§

impl Send for sigaction

§

impl Send for devela::_dep::sdl2::libc::siginfo_t

§

impl Send for signalfd_siginfo

§

impl Send for devela::_dep::sdl2::libc::sigset_t

§

impl Send for sock_extended_err

§

impl Send for sock_filter

§

impl Send for sock_txtime

§

impl Send for devela::_dep::sdl2::libc::sockaddr

§

impl Send for sockaddr_alg

§

impl Send for sockaddr_can

§

impl Send for sockaddr_in6

§

impl Send for sockaddr_in

§

impl Send for sockaddr_ll

§

impl Send for sockaddr_nl

§

impl Send for sockaddr_pkt

§

impl Send for sockaddr_storage

§

impl Send for sockaddr_un

§

impl Send for sockaddr_vm

§

impl Send for sockaddr_xdp

§

impl Send for stat64

§

impl Send for devela::_dep::sdl2::libc::stat

§

impl Send for statfs64

§

impl Send for statfs

§

impl Send for statvfs64

§

impl Send for statvfs

§

impl Send for statx

§

impl Send for statx_timestamp

§

impl Send for sysinfo

§

impl Send for tcp_info

§

impl Send for termios2

§

impl Send for termios

§

impl Send for devela::_dep::sdl2::libc::timespec

§

impl Send for devela::_dep::sdl2::libc::timeval

§

impl Send for timex

§

impl Send for tls12_crypto_info_aes_gcm_128

§

impl Send for tls12_crypto_info_aes_gcm_256

§

impl Send for tls12_crypto_info_chacha20_poly1305

§

impl Send for tls_crypto_info

§

impl Send for tms

§

impl Send for tpacket2_hdr

§

impl Send for tpacket3_hdr

§

impl Send for tpacket_auxdata

§

impl Send for tpacket_bd_ts

§

impl Send for tpacket_block_desc

§

impl Send for tpacket_hdr

§

impl Send for tpacket_hdr_v1

§

impl Send for tpacket_hdr_variant1

§

impl Send for tpacket_req3

§

impl Send for tpacket_req

§

impl Send for tpacket_rollover_stats

§

impl Send for tpacket_stats

§

impl Send for tpacket_stats_v3

§

impl Send for ucred

§

impl Send for uinput_abs_setup

§

impl Send for uinput_ff_erase

§

impl Send for uinput_ff_upload

§

impl Send for uinput_setup

§

impl Send for uinput_user_dev

§

impl Send for user_fpregs_struct

§

impl Send for user_regs_struct

§

impl Send for utimbuf

§

impl Send for utmpx

§

impl Send for utsname

§

impl Send for winsize

§

impl Send for xdp_desc

§

impl Send for xdp_mmap_offsets

§

impl Send for xdp_mmap_offsets_v1

§

impl Send for xdp_options

§

impl Send for xdp_ring_offset

§

impl Send for xdp_ring_offset_v1

§

impl Send for xdp_statistics

§

impl Send for xdp_statistics_v1

§

impl Send for xdp_umem_reg

§

impl Send for xdp_umem_reg_v1

§

impl Send for xsk_tx_metadata

§

impl Send for xsk_tx_metadata_completion

§

impl Send for xsk_tx_metadata_request

§

impl Send for devela::_dep::sdl2::messagebox::MessageBoxButtonFlag

§

impl Send for devela::_dep::sdl2::messagebox::MessageBoxColorScheme

§

impl Send for devela::_dep::sdl2::messagebox::MessageBoxFlag

§

impl Send for devela::_dep::sdl2::mixer::Channel

§

impl Send for devela::_dep::sdl2::mixer::Group

§

impl Send for devela::_dep::sdl2::mixer::InitFlag

§

impl Send for Sdl2MixerContext

§

impl Send for devela::_dep::sdl2::mouse::MouseState

§

impl Send for devela::_dep::sdl2::mouse::RelativeMouseState

§

impl Send for devela::_dep::sdl2::pixels::Color

§

impl Send for devela::_dep::sdl2::pixels::PixelMasks

§

impl Send for devela::_dep::sdl2::rect::FPoint

§

impl Send for devela::_dep::sdl2::rect::FRect

§

impl Send for devela::_dep::sdl2::rect::Point

§

impl Send for devela::_dep::sdl2::rect::Rect

§

impl Send for devela::_dep::sdl2::render::DriverIterator

§

impl Send for devela::_dep::sdl2::render::RendererInfo

§

impl Send for SdlError

§

impl Send for devela::_dep::sdl2::render::TextureQuery

§

impl Send for devela::_dep::sdl2::surface::SurfaceRef

§

impl Send for FPSmanager

§

impl Send for _Mix_Music

§

impl Send for devela::_dep::sdl2::sys::SDL_AudioDeviceEvent

§

impl Send for SDL_BlitMap

§

impl Send for devela::_dep::sdl2::sys::SDL_Color

§

impl Send for devela::_dep::sdl2::sys::SDL_CommonEvent

§

impl Send for SDL_ControllerAxisEvent

§

impl Send for SDL_ControllerButtonEvent

§

impl Send for SDL_ControllerDeviceEvent

§

impl Send for SDL_ControllerSensorEvent

§

impl Send for SDL_ControllerTouchpadEvent

§

impl Send for devela::_dep::sdl2::sys::SDL_Cursor

§

impl Send for devela::_dep::sdl2::sys::SDL_DisplayEvent

§

impl Send for SDL_DollarGestureEvent

§

impl Send for devela::_dep::sdl2::sys::SDL_FPoint

§

impl Send for devela::_dep::sdl2::sys::SDL_FRect

§

impl Send for devela::_dep::sdl2::sys::SDL_Finger

§

impl Send for devela::_dep::sdl2::sys::SDL_GUID

§

impl Send for SDL_GameControllerButtonBind

§

impl Send for SDL_GameControllerButtonBind__bindgen_ty_1__bindgen_ty_1

§

impl Send for devela::_dep::sdl2::sys::SDL_HapticCondition

§

impl Send for devela::_dep::sdl2::sys::SDL_HapticConstant

§

impl Send for devela::_dep::sdl2::sys::SDL_HapticDirection

§

impl Send for devela::_dep::sdl2::sys::SDL_HapticLeftRight

§

impl Send for devela::_dep::sdl2::sys::SDL_HapticPeriodic

§

impl Send for devela::_dep::sdl2::sys::SDL_HapticRamp

§

impl Send for devela::_dep::sdl2::sys::SDL_JoyAxisEvent

§

impl Send for devela::_dep::sdl2::sys::SDL_JoyBallEvent

§

impl Send for devela::_dep::sdl2::sys::SDL_JoyBatteryEvent

§

impl Send for devela::_dep::sdl2::sys::SDL_JoyButtonEvent

§

impl Send for devela::_dep::sdl2::sys::SDL_JoyDeviceEvent

§

impl Send for devela::_dep::sdl2::sys::SDL_JoyHatEvent

§

impl Send for devela::_dep::sdl2::sys::SDL_KeyboardEvent

§

impl Send for SDL_Keysym

§

impl Send for devela::_dep::sdl2::sys::SDL_MessageBoxColor

§

impl Send for devela::_dep::sdl2::sys::SDL_MessageBoxColorScheme

§

impl Send for devela::_dep::sdl2::sys::SDL_MouseButtonEvent

§

impl Send for devela::_dep::sdl2::sys::SDL_MouseMotionEvent

§

impl Send for devela::_dep::sdl2::sys::SDL_MouseWheelEvent

§

impl Send for SDL_MultiGestureEvent

§

impl Send for SDL_OSEvent

§

impl Send for devela::_dep::sdl2::sys::SDL_Point

§

impl Send for devela::_dep::sdl2::sys::SDL_QuitEvent

§

impl Send for devela::_dep::sdl2::sys::SDL_Rect

§

impl Send for devela::_dep::sdl2::sys::SDL_Renderer

§

impl Send for devela::_dep::sdl2::sys::SDL_SensorEvent

§

impl Send for devela::_dep::sdl2::sys::SDL_TextEditingEvent

§

impl Send for devela::_dep::sdl2::sys::SDL_TextInputEvent

§

impl Send for devela::_dep::sdl2::sys::SDL_Texture

§

impl Send for devela::_dep::sdl2::sys::SDL_Thread

§

impl Send for devela::_dep::sdl2::sys::SDL_TouchFingerEvent

§

impl Send for devela::_dep::sdl2::sys::SDL_Vertex

§

impl Send for devela::_dep::sdl2::sys::SDL_Window

§

impl Send for devela::_dep::sdl2::sys::SDL_WindowEvent

§

impl Send for SDL_WindowShapeMode

§

impl Send for SDL_atomic_t

§

impl Send for SDL_cond

§

impl Send for SDL_hid_device_

§

impl Send for SDL_mutex

§

impl Send for SDL_semaphore

§

impl Send for SDL_version

§

impl Send for VkInstance_T

§

impl Send for VkSurfaceKHR_T

§

impl Send for XArc

§

impl Send for XChar2b

§

impl Send for XCharStruct

§

impl Send for XColor

§

impl Send for XExtCodes

§

impl Send for XFontProp

§

impl Send for XFontSetExtents

§

impl Send for XGCValues

§

impl Send for XKeyboardControl

§

impl Send for XKeyboardState

§

impl Send for XPixmapFormatValues

§

impl Send for XPoint

§

impl Send for XRectangle

§

impl Send for XSegment

§

impl Send for XSetWindowAttributes

§

impl Send for XTimeCoord

§

impl Send for XWindowChanges

§

impl Send for _SDL_AudioStream

§

impl Send for _SDL_GameController

§

impl Send for _SDL_Haptic

§

impl Send for _SDL_Joystick

§

impl Send for _SDL_Sensor

§

impl Send for _SDL_iconv_t

§

impl Send for _XDisplay

§

impl Send for _XGC

§

impl Send for _XIC

§

impl Send for _XIM

§

impl Send for _XIMHotKeyTrigger

§

impl Send for _XIMPreeditCaretCallbackStruct

§

impl Send for _XIMPreeditStateNotifyCallbackStruct

§

impl Send for _XImage_funcs

§

impl Send for _XOC

§

impl Send for _XOM

§

impl Send for _XPrivate

§

impl Send for _XrmHashBucketRec

§

impl Send for __BindgenFloat16

§

impl Send for __atomic_wide_counter__bindgen_ty_1

§

impl Send for __fsid_t

§

impl Send for __once_flag

§

impl Send for __pthread_cond_s

§

impl Send for __pthread_rwlock_arch_t

§

impl Send for __sigset_t

§

impl Send for div_t

§

impl Send for drand48_data

§

impl Send for devela::_dep::sdl2::sys::fd_set

§

impl Send for ldiv_t

§

impl Send for lldiv_t

§

impl Send for devela::_dep::sdl2::sys::max_align_t

§

impl Send for devela::_dep::sdl2::sys::timespec

§

impl Send for devela::_dep::sdl2::sys::timeval

§

impl Send for wl_display

§

impl Send for wl_egl_window

§

impl Send for wl_surface

§

impl Send for xdg_popup

§

impl Send for xdg_positioner

§

impl Send for xdg_surface

§

impl Send for xdg_toplevel

§

impl Send for _TTF_Font

§

impl Send for FontStyle

§

impl Send for GlyphMetrics

§

impl Send for Sdl2TtfContext

§

impl Send for devela::_dep::sdl2::version::Version

§

impl Send for devela::_dep::sdl2::video::gl_attr::ContextFlags

§

impl Send for devela::_dep::sdl2::video::DisplayMode

§

impl Send for devela::_dep::sdl2::video::DriverIterator

§

impl Send for devela::_dep::sdl3::audio::AudioSpec

§

impl Send for devela::_dep::sdl3::audio::DriverIterator

§

impl Send for devela::_dep::sdl3::event::EventSender

§

impl Send for SDL_EnumerationResult

§

impl Send for SDL_Folder

§

impl Send for GlobFlags

§

impl Send for PathInfo

§

impl Send for SDL_PathType

§

impl Send for ColorTargetBlendState

§

impl Send for ColorTargetDescription

§

impl Send for DepthStencilState

§

impl Send for RasterizerState

§

impl Send for SamplerCreateInfo

§

impl Send for StencilOpState

§

impl Send for TextureCreateInfo

§

impl Send for devela::_dep::sdl3::gpu::VertexAttribute

§

impl Send for VertexBufferDescription

§

impl Send for JoystickInstance

§

impl Send for devela::_dep::sdl3::joystick::PowerInfo

§

impl Send for devela::_dep::sdl3::keyboard::Mod

§

impl Send for devela::_dep::sdl3::messagebox::MessageBoxButtonFlag

§

impl Send for devela::_dep::sdl3::messagebox::MessageBoxColorScheme

§

impl Send for devela::_dep::sdl3::messagebox::MessageBoxFlag

§

impl Send for devela::_dep::sdl3::mouse::MouseState

§

impl Send for devela::_dep::sdl3::mouse::RelativeMouseState

§

impl Send for devela::_dep::sdl3::pixels::Color

§

impl Send for devela::_dep::sdl3::pixels::PixelFormat

§

impl Send for devela::_dep::sdl3::pixels::PixelMasks

§

impl Send for Properties

§

impl Send for SDL_PropertyType

§

impl Send for devela::_dep::sdl3::rect::Point

§

impl Send for devela::_dep::sdl3::rect::Rect

§

impl Send for devela::_dep::sdl3::render::DriverIterator

§

impl Send for devela::_dep::sdl3::render::FPoint

§

impl Send for devela::_dep::sdl3::render::FRect

§

impl Send for InvalidTextureAccess

§

impl Send for devela::_dep::sdl3::render::RendererInfo

§

impl Send for devela::_dep::sdl3::render::TextureQuery

§

impl Send for devela::_dep::sdl3::Error

§

impl Send for devela::_dep::sdl3::surface::SurfaceRef

§

impl Send for devela::_dep::sdl3::sys::assert::SDL_AssertState

§

impl Send for SDL_AsyncIO

§

impl Send for SDL_AsyncIOQueue

§

impl Send for SDL_AsyncIOResult

§

impl Send for SDL_AsyncIOTaskType

§

impl Send for SDL_AtomicInt

§

impl Send for SDL_AtomicU32

§

impl Send for SDL_AudioFormat

§

impl Send for devela::_dep::sdl3::sys::audio::SDL_AudioSpec

§

impl Send for SDL_AudioStream

§

impl Send for devela::_dep::sdl3::sys::blendmode::SDL_BlendFactor

§

impl Send for devela::_dep::sdl3::sys::blendmode::SDL_BlendOperation

§

impl Send for SDL_Camera

§

impl Send for SDL_CameraPosition

§

impl Send for SDL_CameraSpec

§

impl Send for SDL_FileDialogType

§

impl Send for devela::_dep::sdl3::sys::events::SDL_AudioDeviceEvent

§

impl Send for SDL_CameraDeviceEvent

§

impl Send for devela::_dep::sdl3::sys::events::SDL_CommonEvent

§

impl Send for devela::_dep::sdl3::sys::events::SDL_DisplayEvent

§

impl Send for SDL_EventAction

§

impl Send for devela::_dep::sdl3::sys::events::SDL_EventType

§

impl Send for SDL_GamepadAxisEvent

§

impl Send for SDL_GamepadButtonEvent

§

impl Send for SDL_GamepadDeviceEvent

§

impl Send for SDL_GamepadSensorEvent

§

impl Send for SDL_GamepadTouchpadEvent

§

impl Send for devela::_dep::sdl3::sys::events::SDL_JoyAxisEvent

§

impl Send for devela::_dep::sdl3::sys::events::SDL_JoyBallEvent

§

impl Send for devela::_dep::sdl3::sys::events::SDL_JoyBatteryEvent

§

impl Send for devela::_dep::sdl3::sys::events::SDL_JoyButtonEvent

§

impl Send for devela::_dep::sdl3::sys::events::SDL_JoyDeviceEvent

§

impl Send for devela::_dep::sdl3::sys::events::SDL_JoyHatEvent

§

impl Send for SDL_KeyboardDeviceEvent

§

impl Send for devela::_dep::sdl3::sys::events::SDL_KeyboardEvent

§

impl Send for devela::_dep::sdl3::sys::events::SDL_MouseButtonEvent

§

impl Send for SDL_MouseDeviceEvent

§

impl Send for devela::_dep::sdl3::sys::events::SDL_MouseMotionEvent

§

impl Send for devela::_dep::sdl3::sys::events::SDL_MouseWheelEvent

§

impl Send for SDL_PenAxisEvent

§

impl Send for SDL_PenButtonEvent

§

impl Send for SDL_PenMotionEvent

§

impl Send for SDL_PenProximityEvent

§

impl Send for SDL_PenTouchEvent

§

impl Send for devela::_dep::sdl3::sys::events::SDL_QuitEvent

§

impl Send for SDL_RenderEvent

§

impl Send for devela::_dep::sdl3::sys::events::SDL_SensorEvent

§

impl Send for devela::_dep::sdl3::sys::events::SDL_TouchFingerEvent

§

impl Send for devela::_dep::sdl3::sys::events::SDL_WindowEvent

§

impl Send for SDL_PathInfo

§

impl Send for SDL_Gamepad

§

impl Send for SDL_GamepadAxis

§

impl Send for SDL_GamepadBinding

§

impl Send for SDL_GamepadBindingType

§

impl Send for SDL_GamepadBinding__AnonUnion1__AnonStruct1

§

impl Send for SDL_GamepadBinding__AnonUnion1__AnonStruct2

§

impl Send for SDL_GamepadBinding__AnonUnion2__AnonStruct1

§

impl Send for SDL_GamepadButton

§

impl Send for SDL_GamepadButtonLabel

§

impl Send for SDL_GamepadType

§

impl Send for SDL_GPUBlendFactor

§

impl Send for SDL_GPUBlendOp

§

impl Send for SDL_GPUBuffer

§

impl Send for SDL_GPUBufferCreateInfo

§

impl Send for SDL_GPUColorTargetBlendState

§

impl Send for SDL_GPUColorTargetDescription

§

impl Send for SDL_GPUCommandBuffer

§

impl Send for SDL_GPUCompareOp

§

impl Send for SDL_GPUComputePass

§

impl Send for SDL_GPUComputePipeline

§

impl Send for SDL_GPUCopyPass

§

impl Send for SDL_GPUCubeMapFace

§

impl Send for SDL_GPUCullMode

§

impl Send for SDL_GPUDepthStencilState

§

impl Send for SDL_GPUDevice

§

impl Send for SDL_GPUFence

§

impl Send for SDL_GPUFillMode

§

impl Send for SDL_GPUFilter

§

impl Send for SDL_GPUFrontFace

§

impl Send for SDL_GPUGraphicsPipeline

§

impl Send for SDL_GPUIndexElementSize

§

impl Send for SDL_GPUIndexedIndirectDrawCommand

§

impl Send for SDL_GPUIndirectDispatchCommand

§

impl Send for SDL_GPUIndirectDrawCommand

§

impl Send for SDL_GPULoadOp

§

impl Send for SDL_GPUMultisampleState

§

impl Send for SDL_GPUPresentMode

§

impl Send for SDL_GPUPrimitiveType

§

impl Send for SDL_GPURasterizerState

§

impl Send for SDL_GPURenderPass

§

impl Send for SDL_GPUSampleCount

§

impl Send for SDL_GPUSampler

§

impl Send for SDL_GPUSamplerAddressMode

§

impl Send for SDL_GPUSamplerCreateInfo

§

impl Send for SDL_GPUSamplerMipmapMode

§

impl Send for SDL_GPUShader

§

impl Send for SDL_GPUShaderStage

§

impl Send for SDL_GPUStencilOp

§

impl Send for SDL_GPUStencilOpState

§

impl Send for SDL_GPUStoreOp

§

impl Send for SDL_GPUSwapchainComposition

§

impl Send for SDL_GPUTexture

§

impl Send for SDL_GPUTextureCreateInfo

§

impl Send for SDL_GPUTextureFormat

§

impl Send for SDL_GPUTextureType

§

impl Send for SDL_GPUTransferBuffer

§

impl Send for SDL_GPUTransferBufferCreateInfo

§

impl Send for SDL_GPUTransferBufferUsage

§

impl Send for SDL_GPUVertexAttribute

§

impl Send for SDL_GPUVertexBufferDescription

§

impl Send for SDL_GPUVertexElementFormat

§

impl Send for SDL_GPUVertexInputRate

§

impl Send for SDL_GPUViewport

§

impl Send for devela::_dep::sdl3::sys::guid::SDL_GUID

§

impl Send for SDL_Haptic

§

impl Send for devela::_dep::sdl3::sys::haptic::SDL_HapticCondition

§

impl Send for devela::_dep::sdl3::sys::haptic::SDL_HapticConstant

§

impl Send for devela::_dep::sdl3::sys::haptic::SDL_HapticDirection

§

impl Send for devela::_dep::sdl3::sys::haptic::SDL_HapticLeftRight

§

impl Send for devela::_dep::sdl3::sys::haptic::SDL_HapticPeriodic

§

impl Send for devela::_dep::sdl3::sys::haptic::SDL_HapticRamp

§

impl Send for SDL_hid_bus_type

§

impl Send for SDL_hid_device

§

impl Send for devela::_dep::sdl3::sys::hints::SDL_HintPriority

§

impl Send for SDL_AppResult

§

impl Send for SDL_IOStatus

§

impl Send for SDL_IOStream

§

impl Send for SDL_IOStreamInterface

§

impl Send for SDL_IOWhence

§

impl Send for SDL_Joystick

§

impl Send for SDL_JoystickConnectionState

§

impl Send for devela::_dep::sdl3::sys::joystick::SDL_JoystickType

§

impl Send for SDL_VirtualJoystickSensorDesc

§

impl Send for SDL_VirtualJoystickTouchpadDesc

§

impl Send for SDL_Capitalization

§

impl Send for SDL_TextInputType

§

impl Send for SDL_SharedObject

§

impl Send for devela::_dep::sdl3::sys::log::SDL_LogCategory

§

impl Send for devela::_dep::sdl3::sys::log::SDL_LogPriority

§

impl Send for devela::_dep::sdl3::sys::messagebox::SDL_MessageBoxColor

§

impl Send for devela::_dep::sdl3::sys::messagebox::SDL_MessageBoxColorScheme

§

impl Send for devela::_dep::sdl3::sys::messagebox::SDL_MessageBoxColorType

§

impl Send for devela::_dep::sdl3::sys::mouse::SDL_Cursor

§

impl Send for devela::_dep::sdl3::sys::mouse::SDL_MouseWheelDirection

§

impl Send for devela::_dep::sdl3::sys::mouse::SDL_SystemCursor

§

impl Send for SDL_Condition

§

impl Send for SDL_InitStatus

§

impl Send for SDL_Mutex

§

impl Send for SDL_RWLock

§

impl Send for SDL_Semaphore

§

impl Send for SDL_PenAxis

§

impl Send for devela::_dep::sdl3::sys::pixels::SDL_ArrayOrder

§

impl Send for devela::_dep::sdl3::sys::pixels::SDL_BitmapOrder

§

impl Send for SDL_ChromaLocation

§

impl Send for devela::_dep::sdl3::sys::pixels::SDL_Color

§

impl Send for SDL_ColorPrimaries

§

impl Send for SDL_ColorRange

§

impl Send for SDL_ColorType

§

impl Send for SDL_Colorspace

§

impl Send for SDL_FColor

§

impl Send for SDL_MatrixCoefficients

§

impl Send for devela::_dep::sdl3::sys::pixels::SDL_PackedLayout

§

impl Send for devela::_dep::sdl3::sys::pixels::SDL_PackedOrder

§

impl Send for devela::_dep::sdl3::sys::pixels::SDL_PixelFormat

§

impl Send for SDL_PixelFormatDetails

§

impl Send for devela::_dep::sdl3::sys::pixels::SDL_PixelType

§

impl Send for SDL_TransferCharacteristics

§

impl Send for devela::_dep::sdl3::sys::power::SDL_PowerState

§

impl Send for SDL_Process

§

impl Send for SDL_ProcessIO

§

impl Send for devela::_dep::sdl3::sys::rect::SDL_FPoint

§

impl Send for devela::_dep::sdl3::sys::rect::SDL_FRect

§

impl Send for devela::_dep::sdl3::sys::rect::SDL_Point

§

impl Send for devela::_dep::sdl3::sys::rect::SDL_Rect

§

impl Send for devela::_dep::sdl3::sys::render::SDL_Renderer

§

impl Send for SDL_RendererLogicalPresentation

§

impl Send for devela::_dep::sdl3::sys::render::SDL_Texture

§

impl Send for devela::_dep::sdl3::sys::render::SDL_TextureAccess

§

impl Send for devela::_dep::sdl3::sys::render::SDL_Vertex

§

impl Send for devela::_dep::sdl3::sys::scancode::SDL_Scancode

§

impl Send for SDL_Sensor

§

impl Send for devela::_dep::sdl3::sys::sensor::SDL_SensorType

§

impl Send for SDL_Environment

§

impl Send for SDL_iconv_data_t

§

impl Send for SDL_Storage

§

impl Send for SDL_StorageInterface

§

impl Send for SDL_FlipMode

§

impl Send for devela::_dep::sdl3::sys::surface::SDL_ScaleMode

§

impl Send for SDL_Sandbox

§

impl Send for devela::_dep::sdl3::sys::thread::SDL_Thread

§

impl Send for devela::_dep::sdl3::sys::thread::SDL_ThreadPriority

§

impl Send for SDL_ThreadState

§

impl Send for SDL_DateFormat

§

impl Send for SDL_DateTime

§

impl Send for SDL_TimeFormat

§

impl Send for devela::_dep::sdl3::sys::touch::SDL_Finger

§

impl Send for devela::_dep::sdl3::sys::touch::SDL_TouchDeviceType

§

impl Send for SDL_Tray

§

impl Send for SDL_TrayEntry

§

impl Send for SDL_TrayMenu

§

impl Send for SDL_DisplayModeData

§

impl Send for devela::_dep::sdl3::sys::video::SDL_DisplayOrientation

§

impl Send for devela::_dep::sdl3::sys::video::SDL_FlashOperation

§

impl Send for SDL_GLAttr

§

impl Send for SDL_GLContextState

§

impl Send for devela::_dep::sdl3::sys::video::SDL_HitTestResult

§

impl Send for SDL_SystemTheme

§

impl Send for devela::_dep::sdl3::sys::video::SDL_Window

§

impl Send for VkAllocationCallbacks

§

impl Send for TouchId

§

impl Send for devela::_dep::sdl3::version::Version

§

impl Send for devela::_dep::sdl3::video::gl_attr::ContextFlags

§

impl Send for devela::_dep::sdl3::video::Display

§

impl Send for devela::_dep::sdl3::video::DriverIterator

§

impl Send for IgnoredAny

§

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

§

impl Send for devela::_dep::simdutf8::basic::Utf8Error

§

impl Send for devela::_dep::simdutf8::compat::Utf8Error

§

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 devela::_dep::symphonia::core::meta::Visual

§

impl Send for Descriptor

§

impl Send for devela::_dep::symphonia::core::probe::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 devela::_dep::sysinfo::Group

§

impl Send for devela::_dep::sysinfo::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 devela::_dep::tokio::process::Child

§

impl Send for devela::_dep::tokio::process::ChildStderr

§

impl Send for devela::_dep::tokio::process::ChildStdin

§

impl Send for devela::_dep::tokio::process::ChildStdout

§

impl Send for devela::_dep::tokio::process::Command

§

impl Send for devela::_dep::tokio::runtime::Builder

§

impl Send for Handle

§

impl Send for Runtime

§

impl Send for RuntimeMetrics

§

impl Send for TryCurrentError

§

impl Send for devela::_dep::tokio::sync::oneshot::error::RecvError

§

impl Send for AcquireError

§

impl Send for devela::_dep::tokio::sync::Barrier

§

impl Send for devela::_dep::tokio::sync::BarrierWaitResult

§

impl Send for Notify

§

impl Send for OwnedSemaphorePermit

§

impl Send for Semaphore

§

impl Send for devela::_dep::tokio::sync::TryLockError

§

impl Send for devela::_dep::tokio::sync::watch::error::RecvError

§

impl Send for devela::_dep::tokio::task::Id

§

impl Send for JoinError

§

impl Send for devela::_dep::toml_edit::de::Error

§

impl Send for ValueDeserializer

§

impl Send for ValueSerializer

§

impl Send for devela::_dep::toml_edit::Array

§

impl Send for ArrayOfTables

§

impl Send for devela::_dep::toml_edit::Date

§

impl Send for Datetime

§

impl Send for DatetimeParseError

§

impl Send for Decor

§

impl Send for DocumentMut

§

impl Send for InlineTable

§

impl Send for InternalString

§

impl Send for devela::_dep::toml_edit::Key

§

impl Send for RawString

§

impl Send for Repr

§

impl Send for devela::_dep::toml_edit::Table

§

impl Send for devela::_dep::toml_edit::Time

§

impl Send for TomlError

§

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 devela::_dep::tracing::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 Config

§

impl Send for Timeouts

§

impl Send for InvalidHeaderName

§

impl Send for InvalidHeaderValue

§

impl Send for MaxSizeReached

§

impl Send for ToStrError

§

impl Send for InvalidMethod

§

impl Send for devela::_dep::ureq::http::request::Builder

§

impl Send for devela::_dep::ureq::http::request::Parts

§

impl Send for devela::_dep::ureq::http::response::Builder

§

impl Send for devela::_dep::ureq::http::response::Parts

§

impl Send for InvalidStatusCode

§

impl Send for devela::_dep::ureq::http::Error

§

impl Send for Extensions

§

impl Send for HeaderName

§

impl Send for HeaderValue

§

impl Send for Method

§

impl Send for StatusCode

§

impl Send for Uri

§

impl Send for devela::_dep::ureq::http::Version

§

impl Send for Authority

§

impl Send for devela::_dep::ureq::http::uri::Builder

§

impl Send for InvalidUri

§

impl Send for InvalidUriParts

§

impl Send for devela::_dep::ureq::http::uri::Parts

§

impl Send for PathAndQuery

§

impl Send for devela::_dep::ureq::http::uri::Scheme

§

impl Send for Agent

§

impl Send for Body

§

impl Send for BodyBuilder

§

impl Send for devela::_dep::ureq::Proxy

§

impl Send for AgentScope

§

impl Send for WithBody

§

impl Send for WithoutBody

§

impl Send for DefaultResolver

§

impl Send for ConnectProxyConnector

§

impl Send for DefaultConnector

§

impl Send for LazyBuffers

§

impl Send for NextTimeout

§

impl Send for TcpConnector

§

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 EmptyError

§

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 Char

§

impl Send for GraphemeString

§

impl Send for InvalidChar

§

impl Send for InvalidUtf8

§

impl Send for char7

§

impl Send for char8

§

impl Send for char16

§

impl Send for AddrParseError

§

impl Send for Alloc

§

impl Send for AppApple

§

impl Send for AppConfig

§

impl Send for AppUnix

§

impl Send for AppWindows

§

impl Send for AppXdg

§

impl Send for Arch

§

impl Send for devela::all::AtomicBool

§

impl Send for AtomicF32

§

impl Send for AtomicF64

§

impl Send for devela::all::AtomicI8

§

impl Send for devela::all::AtomicI16

§

impl Send for devela::all::AtomicI32

§

impl Send for devela::all::AtomicI64

§

impl Send for AtomicI128

§

impl Send for devela::all::AtomicIsize

§

impl Send for devela::all::AtomicU8

§

impl Send for devela::all::AtomicU16

§

impl Send for devela::all::AtomicU32

§

impl Send for devela::all::AtomicU64

§

impl Send for AtomicU128

§

impl Send for devela::all::AtomicUsize

§

impl Send for Backtrace

§

impl Send for devela::all::Barrier

§

impl Send for devela::all::BarrierWaitResult

§

impl Send for Boxed

§

impl Send for ByteSearch

§

impl Send for devela::all::CStr

§

impl Send for devela::all::CString

§

impl Send for CodecFlags

§

impl Send for CodecLen

§

impl Send for devela::all::Color

§

impl Send for Condvar

§

impl Send for Crockford

§

impl Send for CrosstermService

§

impl Send for DataOverflow

§

impl Send for DirBuilder

§

impl Send for devela::all::DirEntry

§

impl Send for DrumFrame8

§

impl Send for devela::all::Duration

§

impl Send for TryFromFloatSecsError

§

impl Send for ElementNotFound

§

impl Send for Env

§

impl Send for FailedErrorConversion

§

impl Send for devela::all::False

§

impl Send for devela::all::File

§

impl Send for devela::all::FileMetadata

§

impl Send for OpenOptions

§

impl Send for Permissions

§

impl Send for FileTimes

§

impl Send for devela::all::FileType

§

impl Send for Fmt

§

impl Send for devela::all::FmtError

§

impl Send for Fs

§

impl Send for FsPath

§

impl Send for HasherPengy

§

impl Send for IdPinBox

§

impl Send for IndexOutOfBounds

§

impl Send for InvalidAxisLength

§

impl Send for Io

§

impl Send for devela::all::IoEmpty

§

impl Send for devela::all::IoError

§

impl Send for devela::all::IoRepeat

§

impl Send for devela::all::IoSink

§

impl Send for Ipv4Addr

§

impl Send for Ipv6Addr

§

impl Send for devela::all::Iter

§

impl Send for ReadDir

§

impl Send for JoinPathsError

§

impl Send for Js

§

impl Send for KeyAlreadyExists

§

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 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 Log

§

impl Send for LogConfig

§

impl Send for SetLoggerError

§

impl Send for Maybe

§

impl Send for Mem

§

impl Send for devela::all::MemLayout

§

impl Send for devela::all::MemLayoutError

§

impl Send for MiniquadWindow

§

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 NotImplemented

§

impl Send for NotSupported

§

impl Send for devela::all::Once

§

impl Send for OnceState

§

impl Send for OsStr

§

impl Send for OsString

§

impl Send for Panic

§

impl Send for ParseFloatError

§

impl Send for ParseIntError

§

impl Send for PartiallyAdded

§

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 devela::all::Process

§

impl Send for devela::all::ProcessCommand

§

impl Send for ExitCode

§

impl Send for ExitStatus

§

impl Send for devela::all::ProcessOutput

§

impl Send for devela::all::ProcessStderr

§

impl Send for devela::all::ProcessStdin

§

impl Send for Stdio

§

impl Send for devela::all::ProcessStdout

§

impl Send for Ptr

§

impl Send for RandomState

§

impl Send for RangeFull

§

impl Send for BorrowError

§

impl Send for BorrowMutError

§

impl Send for Rfc4648

§

impl Send for Rfc4648Hex

§

impl Send for SleepSpin

§

impl Send for SocketAddrV4

§

impl Send for SocketAddrV6

§

impl Send for devela::all::Stderr

§

impl Send for devela::all::Stdin

§

impl Send for devela::all::Stdout

§

impl Send for Str

§

impl Send for devela::all::String

§

impl Send for devela::all::SystemAlloc

§

impl Send for devela::all::SystemInstant

§

impl Send for SystemTime

§

impl Send for devela::all::SystemTimeError

§

impl Send for RawWakerVTable

§

impl Send for TcpListener

§

impl Send for TcpStream

§

impl Send for Thread

§

impl Send for AccessError

§

impl Send for devela::all::ThreadBuilder

§

impl Send for ThreadId

§

impl Send for TimeDelta

§

impl Send for Timecode

§

impl Send for devela::all::True

§

impl Send for devela::all::TryFromIntError

§

impl Send for UdpSocket

§

impl Send for UiCap

§

impl Send for UiCapImage

§

impl Send for UiCapInput

§

impl Send for UiCapSound

§

impl Send for UiCapSystem

§

impl Send for UiCapWindow

§

impl Send for UnixTimeI64

§

impl Send for UnixTimeU32

§

impl Send for WaitTimeoutResult

§

impl Send for WaveletHaar

§

impl Send for WaveletUnitVec

§

impl Send for Xabc

§

impl Send for XorShift128

§

impl Send for XorShift128p

§

impl Send for Xoroshiro128pp

§

impl Send for Xyza8a

§

impl Send for Xyza8b

§

impl Send for g_bvec2

§

impl Send for g_bvec3

§

impl Send for g_bvec4

§

impl Send for g_dmat2

§

impl Send for g_dmat3

§

impl Send for g_dmat4

§

impl Send for g_dvec2

§

impl Send for g_dvec3

§

impl Send for g_dvec4

§

impl Send for g_ivec2

§

impl Send for g_ivec3

§

impl Send for g_ivec4

§

impl Send for g_mat2

§

impl Send for g_mat2x3

§

impl Send for g_mat2x4

§

impl Send for g_mat3

§

impl Send for g_mat3x2

§

impl Send for g_mat3x4

§

impl Send for g_mat4

§

impl Send for g_mat4x2

§

impl Send for g_mat4x3

§

impl Send for g_uvec2

§

impl Send for g_uvec3

§

impl Send for g_uvec4

§

impl Send for g_vec2

§

impl Send for g_vec3

§

impl Send for g_vec4

§

impl Send for g_vertex2

§

impl Send for g_vertex3

§

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 devela::_dep::nc::siginfo_t

§

impl Send for sigval_t

§

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 __c_anonymous_iwreq

§

impl Send for __c_anonymous_ptp_perout_request_1

§

impl Send for __c_anonymous_ptp_perout_request_2

§

impl Send for __c_anonymous_ptrace_syscall_info_data

§

impl Send for __c_anonymous_sockaddr_can_can_addr

§

impl Send for __c_anonymous_xsk_tx_metadata_union

§

impl Send for tpacket_bd_header_u

§

impl Send for tpacket_req_u

§

impl Send for SDL_GameControllerButtonBind__bindgen_ty_1

§

impl Send for SDL_WindowShapeParams

§

impl Send for XClientMessageEvent__bindgen_ty_1

§

impl Send for __atomic_wide_counter

§

impl Send for devela::_dep::sdl2::sys::pthread_attr_t

§

impl Send for devela::_dep::sdl2::sys::pthread_barrier_t

§

impl Send for devela::_dep::sdl2::sys::pthread_barrierattr_t

§

impl Send for devela::_dep::sdl2::sys::pthread_cond_t

§

impl Send for devela::_dep::sdl2::sys::pthread_condattr_t

§

impl Send for devela::_dep::sdl2::sys::pthread_mutexattr_t

§

impl Send for devela::_dep::sdl2::sys::pthread_rwlock_t

§

impl Send for devela::_dep::sdl2::sys::pthread_rwlockattr_t

§

impl Send for SDL_GamepadBinding__AnonUnion1

§

impl Send for SDL_GamepadBinding__AnonUnion2

§

impl Send for DataRaw64Copy

§

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 PyObjectFreeList

§

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 devela::_core::error::Request<'a>

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<'a> !Send for Frames<'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 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 devela::_dep::rustix::event::epoll::Iter<'a>

§

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

§

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

§

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

§

impl<'a> !Send for devela::_dep::sdl2::surface::Surface<'a>

§

impl<'a> !Send for devela::_dep::sdl2::surface::SurfaceContext<'a>

§

impl<'a> !Send for devela::_dep::sdl2::video::gl_attr::ContextFlagsBuilder<'a>

§

impl<'a> !Send for devela::_dep::sdl2::video::gl_attr::GLAttr<'a>

§

impl<'a> !Send for devela::_dep::sdl2::video::WindowSurfaceRef<'a>

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<'a> !Send for devela::_dep::sdl3::gpu::Texture<'a>

§

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

§

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

§

impl<'a> !Send for devela::_dep::sdl3::surface::Surface<'a>

§

impl<'a> !Send for devela::_dep::sdl3::surface::SurfaceContext<'a>

§

impl<'a> !Send for devela::_dep::sdl3::video::gl_attr::ContextFlagsBuilder<'a>

§

impl<'a> !Send for devela::_dep::sdl3::video::gl_attr::GLAttr<'a>

§

impl<'a> !Send for devela::_dep::sdl3::video::WindowSurfaceRef<'a>

§

impl<'a> !Send for EnterGuard<'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 SendBody<'a>

§

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

§

impl<'a> !Send for devela::all::LogRecord<'a>

§

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

§

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

§

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

§

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

§

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

§

impl<'a> !Send for devela::all::TaskContext<'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 devela::_dep::sdl2::messagebox::ClickedButton<'a>

§

impl<'a> Send for devela::_dep::sdl3::messagebox::ClickedButton<'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::_dep::toml_edit::Entry<'a>

§

impl<'a> Send for InlineEntry<'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 PhantomContravariantLifetime<'a>

§

impl<'a> Send for PhantomCovariantLifetime<'a>

§

impl<'a> Send for PhantomInvariantLifetime<'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 devela::_dep::_std::ffi::os_str::Display<'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 AxisDataIter<'a>

§

impl<'a> Send for ButtonDataIter<'a>

§

impl<'a> Send for devela::_dep::gilrs::Gamepad<'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::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 FdSetIter<'a>

§

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

§

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

§

impl<'a> Send for devela::_dep::sdl2::event::EventPollIterator<'a>

§

impl<'a> Send for devela::_dep::sdl2::event::EventWaitIterator<'a>

§

impl<'a> Send for devela::_dep::sdl2::event::EventWaitTimeoutIterator<'a>

§

impl<'a> Send for devela::_dep::sdl2::keyboard::KeyboardState<'a>

§

impl<'a> Send for devela::_dep::sdl2::keyboard::ScancodeIterator<'a>

§

impl<'a> Send for devela::_dep::sdl2::messagebox::ButtonData<'a>

§

impl<'a> Send for devela::_dep::sdl2::mouse::MouseButtonIterator<'a>

§

impl<'a> Send for DialogFileFilter<'a>

§

impl<'a> Send for devela::_dep::sdl3::event::EventPollIterator<'a>

§

impl<'a> Send for devela::_dep::sdl3::event::EventWaitIterator<'a>

§

impl<'a> Send for devela::_dep::sdl3::event::EventWaitTimeoutIterator<'a>

§

impl<'a> Send for devela::_dep::sdl3::keyboard::KeyboardState<'a>

§

impl<'a> Send for PressedScancodeIterator<'a>

§

impl<'a> Send for devela::_dep::sdl3::keyboard::ScancodeIterator<'a>

§

impl<'a> Send for devela::_dep::sdl3::messagebox::ButtonData<'a>

§

impl<'a> Send for devela::_dep::sdl3::mouse::MouseButtonIterator<'a>

§

impl<'a> Send for PressedMouseButtonIterator<'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 SemaphorePermit<'a>

§

impl<'a> Send for InlineOccupiedEntry<'a>

§

impl<'a> Send for InlineVacantEntry<'a>

§

impl<'a> Send for devela::_dep::toml_edit::OccupiedEntry<'a>

§

impl<'a> Send for devela::_dep::toml_edit::VacantEntry<'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 MiddlewareNext<'a>

§

impl<'a> Send for BodyReader<'a>

§

impl<'a> Send for BodyWithConfig<'a>

§

impl<'a> Send for ConnectionDetails<'a>

§

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

§

impl<'a> Send for IdPin<'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 SplitPaths<'a>

§

impl<'a> Send for devela::all::LogMetadata<'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 CommandArgs<'a>

§

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

§

impl<'a> Send for Sixel<'a>

§

impl<'a> Send for devela::all::TcpIncoming<'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 devela::_core::ffi::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, CB> !Send for AudioDeviceLockGuard<'a, CB>

§

impl<'a, CB> Send for devela::_dep::sdl2::event::EventWatch<'a, CB>
where CB: Send + Sync,

§

impl<'a, CB> Send for devela::_dep::sdl3::event::EventWatch<'a, CB>
where CB: Send + Sync,

§

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 devela::_dep::itertools::Chunk<'a, I>

§

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

§

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

§

impl<'a, I> Send for devela::_dep::image::Pixels<'a, I>
where I: Sync + ?Sized,

§

impl<'a, I> Send for Format<'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, I, E> Send for ProcessResults<'a, I, E>
where I: Send, E: Send,

§

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

§

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

§

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

§

impl<'a, K> Send for 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, I, F> !Send for devela::_dep::itertools::Group<'a, K, I, F>

§

impl<'a, K, I, F> !Send for devela::_dep::itertools::Groups<'a, K, I, F>

§

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, 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 EnumeratePixels<'a, P>
where <P as Pixel>::Subpixel: Sync,

§

impl<'a, P> Send for EnumeratePixelsMut<'a, P>
where <P as Pixel>::Subpixel: Send,

§

impl<'a, P> Send for EnumeratePixelsMutPar<'a, P>

§

impl<'a, P> Send for EnumeratePixelsPar<'a, P>

§

impl<'a, P> Send for EnumerateRows<'a, P>
where <P as Pixel>::Subpixel: Sync,

§

impl<'a, P> Send for EnumerateRowsMut<'a, P>
where <P as Pixel>::Subpixel: Send,

§

impl<'a, P> Send for devela::_dep::image::buffer::Pixels<'a, P>
where <P as Pixel>::Subpixel: Sync,

§

impl<'a, P> Send for PixelsMut<'a, P>
where <P as Pixel>::Subpixel: Send,

§

impl<'a, P> Send for PixelsMutPar<'a, P>

§

impl<'a, P> Send for PixelsPar<'a, P>

§

impl<'a, P> Send for Rows<'a, P>
where <P as Pixel>::Subpixel: Sync,

§

impl<'a, P> Send for RowsMut<'a, P>
where <P as Pixel>::Subpixel: 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 BufferMemMap<'a, T>

§

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

§

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

§

impl<'a, T> Send for devela::_dep::ureq::http::header::Entry<'a, T>
where T: Send,

§

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::flume::Drain<'a, T>
where T: Send,

§

impl<'a, T> Send for devela::_dep::flume::Iter<'a, T>
where T: Send,

§

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

§

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 Permit<'a, T>
where T: Send,

§

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

§

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

§

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

§

impl<'a, T> Send for devela::_dep::ureq::http::header::Keys<'a, T>
where T: Sync,

§

impl<'a, T> Send for devela::_dep::ureq::http::header::OccupiedEntry<'a, T>
where T: Send,

§

impl<'a, T> Send for devela::_dep::ureq::http::header::VacantEntry<'a, T>
where T: Send,

§

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

§

impl<'a, T> Send for devela::_dep::ureq::http::header::Values<'a, T>
where T: Sync,

§

impl<'a, T> Send for devela::_dep::ureq::http::header::ValuesMut<'a, T>
where T: Send,

§

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, U> Send for TextStyle<'a, U>
where U: Send,

§

impl<'a, V> Send for StaticMapEntry<'a, V>
where V: 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, 'a> Send for devela::_dep::sdl2::timer::Timer<'b, 'a>

§

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<'d> Send for TimeZoneName<'d>

§

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

§

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<'f, 'text> !Send for PartialRendering<'f, 'text>

§

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

§

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

§

impl<'glyphs, T> Send for BitmapFont<'glyphs, T>
where T: Sync,

§

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<'k> Send for KeyMut<'k>

§

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, I, O, E> Send for ByRef<'p, P, I, O, E>
where P: Send, I: Send, O: Send, E: 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 devela::_dep::sdl2::render::Texture<'r>

§

impl<'r> !Send for devela::_dep::sdl3::render::Texture<'r>

§

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<'r, R> Send for UnwrapMut<'r, R>
where R: Send + ?Sized,

§

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::all::ThreadScope<'scope, 'env>

§

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

§

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

§

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

§

impl<'t> Send for TimeZoneOffsetInfo<'t>

§

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

§

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

§

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

§

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

§

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<'ttf_module, 'rwops> !Send for devela::_dep::sdl2::ttf::Font<'ttf_module, 'rwops>

§

impl<A> !Send for VecChunk<A>

§

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 devela::_dep::itertools::RepeatN<A>
where A: Send,

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<A, B> Send for devela::_dep::ureq::unversioned::transport::Either<A, B>
where A: Send, B: 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 devela::_dep::rayon::iter::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<Any> Send for RequestScope<Any>
where Any: 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 RequestBuilder<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<Buffer> Send for FlatSamples<Buffer>
where Buffer: Send,

§

impl<Buffer, P> Send for View<Buffer, P>
where Buffer: Send, P: Send,

§

impl<Buffer, P> Send for ViewMut<Buffer, P>
where Buffer: Send, P: Send,

§

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

§

impl<CB> !Send for devela::_dep::sdl2::audio::AudioDevice<CB>

§

impl<CB> !Send for AudioStreamWithCallback<CB>

§

impl<Channel> !Send for AudioQueue<Channel>

§

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> Send for CodecLe<E>
where E: Send,

§

impl<E, CodecEndian> Send for CodecLenValue<E, CodecEndian>
where E: Send, CodecEndian: Send,

§

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

§

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

§

impl<E, S> Send for CodecJoin<E, S>
where E: Send, S: 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 Unconstrained<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::impls::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::impls::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 devela::_dep::winnow::combinator::impls::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::impls::Take<F, I, O, E>
where F: Send, I: Send, O: Send, E: Send,

§

impl<F, I, O, E> Send for Void<F, I, O, E>
where F: Send, I: Send, O: Send, E: Send,

§

impl<F, I, O, E> Send for WithSpan<F, I, O, E>
where F: Send, I: Send, O: Send, E: Send,

§

impl<F, I, O, E> Send for WithTaken<F, I, O, E>
where F: Send, I: Send, O: Send, E: Send,

§

impl<F, I, O, E> Send for ParserIterator<F, I, O, E>
where F: Send, I: Send, E: Send, O: Send,

§

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

§

impl<F, T> Send for 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<G> Send for FromCoroutine<G>
where G: 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 RcIter<I>

§

impl<I> !Send for Tee<I>

§

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 SubImage<I>
where I: Send,

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<I> Send for devela::_dep::itertools::WhileSome<I>
where I: Send,

§

impl<I> Send for WithPosition<I>
where I: Send, <I as Iterator>::Item: 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 devela::_dep::rayon::iter::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 devela::_dep::rodio::source::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 devela::all::IterCycle<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, ElemF> Send for devela::_dep::itertools::IntersperseWith<I, ElemF>
where ElemF: Send, I: Send, <I as Iterator>::Item: Send,

§

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

§

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

§

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

§

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

§

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

§

impl<I, F> Send for devela::_dep::itertools::Positions<I, F>
where F: Send, I: Send,

§

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

§

impl<I, F> Send for devela::_dep::itertools::Update<I, F>
where I: Send, F: 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 devela::_dep::rayon::iter::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 devela::_core::iter::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 Diff<I, J>
where I: Send, J: Send, <I as Iterator>::Item: Send, <J as Iterator>::Item: Send,

§

impl<I, J> Send for devela::_dep::itertools::Interleave<I, J>
where I: Send, J: Send,

§

impl<I, J> Send for devela::_dep::itertools::InterleaveShortest<I, J>
where I: Send, J: Send,

§

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

§

impl<I, J> Send for devela::_dep::itertools::ZipEq<I, J>
where I: Send, J: Send,

§

impl<I, J> Send for devela::_dep::rayon::iter::Interleave<I, J>

§

impl<I, J> Send for devela::_dep::rayon::iter::InterleaveShortest<I, J>

§

impl<I, J, F> Send for MergeBy<I, J, F>
where F: Send, <I as Iterator>::Item: Send, <J as Iterator>::Item: Send, I: Send, J: Send,

§

impl<I, 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 devela::_dep::rayon::iter::Positions<I, P>
where P: Send,

§

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

§

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

§

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

§

impl<I, T> Send for TupleCombinations<I, T>
where <T as HasCombination<I>>::Combination: Send, I: Send,

§

impl<I, T> Send for TupleWindows<I, T>
where I: Send, T: Send,

§

impl<I, T> Send for Tuples<I, T>
where <T as TupleCollect>::Buffer: Send, I: Send,

§

impl<I, T, E> Send for FlattenOk<I, T, E>
where I: Send, <T as IntoIterator>::IntoIter: Send,

§

impl<I, T, F> Send for MapWith<I, T, F>
where T: Send, F: Send,

§

impl<I, U, F> Send for FoldChunksWith<I, U, F>
where U: Send, F: Send,

§

impl<I, U, F> Send for FoldWith<I, U, F>
where I: Send, U: Send, F: Send,

§

impl<I, U, F> Send for TryFoldWith<I, U, F>
where I: Send, <U as Try>::Output: Send, F: Send,

§

impl<I, U, F> Send for 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, V, F> Send for UniqueBy<I, V, F>
where I: Send, F: Send, V: 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<In, First, Second> Send for ChainedConnector<In, First, Second>
where First: Send, Second: Send, In: 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, I, F> Send for devela::_dep::itertools::ChunkBy<K, I, F>
where F: Send, I: Send, K: Send, <I as Iterator>::Item: 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, 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, 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 N: usize> Send for ExampleStaticMapU16<K, V, N>
where K: Send, V: Send,

§

impl<L, R> Send for devela::_dep::itertools::Either<L, R>
where L: Send, R: Send,

§

impl<N, H> Send for Mismatch<N, H>
where N: Send, H: 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, Container> Send for ImageBuffer<P, Container>
where Container: Send, 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, E> Send for CompleteErr<P, I, O, E>
where P: Send, I: Send, O: Send, E: Send,

§

impl<P, I, O, O2, E> Send for ParseTo<P, I, O, O2, E>
where P: Send, I: Send, O: Send, O2: Send, E: Send,

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<R> Send for BlockRng64<R>
where <R as BlockRngCore>::Results: Send, R: Send + ?Sized,

§

impl<R> Send for BlockRng<R>
where <R as BlockRngCore>::Results: Send, R: Send,

§

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

§

impl<R> Send for 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, T> Send for StreamingContextConsistencyTester<R, T>
where T: Send, 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 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> Send for Deserializer<S>
where S: Send,

§

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

§

impl<S> Send for HttpCrateScope<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<Scope> Send for ConfigBuilder<Scope>
where Scope: Send,

§

impl<St, F> Send for Iterate<St, F>
where St: Send, F: Send,

§

impl<St, F> Send for Unfold<St, F>
where F: Send, St: Send,

§

impl<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 devela::_dep::sdl2::render::Canvas<T>

§

impl<T> !Send for devela::_dep::sdl2::render::RendererContext<T>

§

impl<T> !Send for devela::_dep::sdl2::render::TextureCreator<T>

§

impl<T> !Send for devela::_dep::sdl3::render::Canvas<T>

§

impl<T> !Send for devela::_dep::sdl3::render::RendererContext<T>

§

impl<T> !Send for devela::_dep::sdl3::render::TextureCreator<T>

§

impl<T> !Send for Closure<T>

§

impl<T> !Send for RcRef<T>

§

impl<T> !Send for RcRefMut<T>

§

impl<T> Send for devela::_core::option::Option<T>
where T: Send,

§

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

§

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

§

impl<T> Send for devela::_dep::flume::SendTimeoutError<T>
where T: Send,

§

impl<T> Send for devela::_dep::flume::TrySendError<T>
where T: Send,

§

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

§

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

§

impl<T> Send for devela::_dep::kira::Value<T>
where T: Send,

§

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

§

impl<T> Send for devela::_dep::tokio::sync::mpsc::error::TrySendError<T>
where T: Send,

§

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

§

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

§

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

§

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

§

impl<T> Send for devela::all::TryLockError<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 PhantomContravariant<T>
where T: ?Sized,

§

impl<T> Send for PhantomCovariant<T>
where T: ?Sized,

§

impl<T> Send for PhantomInvariant<T>
where 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 GlobalState<T>

§

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

§

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

§

impl<T> Send for devela::_dep::fltk::utils::oncelock::OnceCell<T>
where T: Send,

§

impl<T> Send for devela::_dep::flume::IntoIter<T>
where T: Send,

§

impl<T> Send for devela::_dep::flume::Receiver<T>
where T: Send,

§

impl<T> Send for devela::_dep::flume::SendError<T>
where T: Send,

§

impl<T> Send for devela::_dep::flume::Sender<T>
where T: Send,

§

impl<T> Send for devela::_dep::flume::WeakSender<T>
where T: Send,

§

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

§

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

§

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

§

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

§

impl<T> Send for TupleBuffer<T>
where <T as TupleCollect>::Buffer: Send,

§

impl<T> Send for devela::_dep::itertools::Zip<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 devela::_dep::tokio::sync::broadcast::error::SendError<T>
where T: Send,

§

impl<T> Send for devela::_dep::tokio::sync::mpsc::error::SendError<T>
where T: Send,

§

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

§

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

§

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

§

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

§

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

§

impl<T> Send for devela::_dep::tokio::sync::mpsc::WeakSender<T>
where T: Send,

§

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

§

impl<T> Send for devela::_dep::tokio::sync::oneshot::Receiver<T>
where T: Send,

§

impl<T> Send for devela::_dep::tokio::sync::oneshot::Sender<T>
where T: Send,

§

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

§

impl<T> Send for devela::_dep::tokio::sync::watch::error::SendError<T>
where T: Send,

§

impl<T> Send for devela::_dep::tokio::sync::watch::Receiver<T>
where T: Send + Sync,

§

impl<T> Send for devela::_dep::tokio::sync::watch::Sender<T>
where T: Send + Sync,

§

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

§

impl<T> Send for devela::_dep::tokio::task::LocalKey<T>

§

impl<T> Send for devela::_dep::toml_edit::Formatted<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 devela::_dep::ureq::http::header::IntoIter<T>
where T: Send,

§

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

§

impl<T> Send for devela::_dep::ureq::http::Request<T>
where T: Send,

§

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

§

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

§

impl<T> Send for TransportAdapter<T>

§

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 Sort<T>
where T: Send,

§

impl<T> Send for Cast<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 Tp<T>
where T: Send,

§

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

§

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

§

impl<T> Send for devela::all::Atomic<T>
where T: Send,

§

impl<T> Send for devela::all::AtomicPtr<T>

§

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

§

impl<T> Send for devela::all::Compare<T>
where T: Send,

§

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

§

impl<T> Send for devela::all::Cycle<T>
where T: Send,

§

impl<T> Send for Discriminant<T>

§

impl<T> Send for Pending<T>

§

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

§

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

§

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

§

impl<T> Send for Interval<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 MiniquadService<T>
where T: Send,

§

impl<T> Send for devela::all::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 PoisonError<T>
where T: Send,

§

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

§

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

§

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

§

impl<T> Send for devela::all::ThreadLocalKey<T>

§

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 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 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> Send for XofContextConsistencyTester<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 Result<T, E>
where T: Send, E: Send,

§

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

§

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

§

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

§

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 LazyLock<T, F>
where T: Send, F: Send,

§

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

§

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

§

impl<T, K, C> Send for KemTester<T, K, C>
where T: Send, K: Send, C: Send,

§

impl<T, N> Send for CycleCount<T, N>
where N: Send, T: Send,

§

impl<T, P> Send for Split<T, P>
where T: Send, P: Send,

§

impl<T, P> Send for SplitInclusive<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 ZipLongest<T, U>
where T: Send, U: 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, 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 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 devela::all::Array<T, CAP, S>
where <S as Storage>::Stored<[T; CAP]>: 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 Distance<T, D>
where T: Send,

§

impl<T, const D: usize> Send for Extent<T, D>
where T: Send,

§

impl<T, const D: usize> Send for devela::all::Orientation<T, D>
where T: Send,

§

impl<T, const D: usize> Send for devela::all::Point<T, D>
where T: Send,

§

impl<T, const D: usize> Send for devela::all::Position<T, D>
where T: Send,

§

impl<T, const D: usize> Send for devela::all::Region<T, D>
where T: Send,

§

impl<T, const D: usize> Send for RegionStrided<T, D>
where T: Send,

§

impl<T, const D: usize> Send for Stride<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 LEN: usize> Send for Affine<T, D, LEN>
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 ArrayVec<T, N>
where T: Send,

§

impl<T, const N: usize> Send for devela::all::ArrayIntoIter<T, N>
where T: Send,

§

impl<T, const R: usize, const C: usize, const LEN: usize, const RMAJ: bool, const MAX_LEN_DET: usize> Send for Matrix<T, R, C, LEN, RMAJ, MAX_LEN_DET>
where T: Send,

§

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

§

impl<U> Send for devela::_dep::fontdue::layout::Layout<U>
where U: Send,

§

impl<V> Send for DataValue64CopyWith<V>
where V: Send,

§

impl<V> Send for DataValue64With<V>
where V: 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 JpegEncoder<W>
where W: Send,

§

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

§

impl<W> Send for PnmEncoder<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 devela::_dep::tokio::io::BufWriter<W>
where W: Send,

§

impl<W> Send for CodecBe<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<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 A: usize, const B: usize, const C: usize> Send for XorShift8<A, B, C>

§

impl<const BASIS: usize, const A: usize, const B: usize, const C: usize> Send for XorShift16<BASIS, A, B, C>

§

impl<const BASIS: usize, const A: usize, const B: usize, const C: usize> Send for XorShift32<BASIS, A, B, C>

§

impl<const BASIS: usize, const A: usize, const B: usize, const C: usize> Send for XorShift64<BASIS, A, B, C>

§

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 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 RADIX: usize, const LUT: bool, const PAD: bool, const CASE: bool, CODE> Send for Base<RADIX, LUT, PAD, CASE, CODE>
where CODE: Send,

§

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>