Trait sp_std::marker::Send

1.0.0 · source · []
pub unsafe auto trait Send { }
Expand description

Types that can be transferred across thread boundaries.

This trait is automatically implemented when the compiler determines it’s appropriate.

An example of a non-Send type is the reference-counting pointer rc::Rc. If two threads attempt to clone Rcs that point to the same reference-counted value, they might try to update the reference count at the same time, which is undefined behavior because Rc doesn’t use atomic operations. Its cousin sync::Arc does use atomic operations (incurring some overhead) and thus is Send.

See the Nomicon for more details.

Implementations on Foreign Types

Implementors

NonNull pointers are not Send because the data they reference may be aliased.

impl<Block: BlockT, C: CallApiAt<Block>> Send for RuntimeApiImpl<Block, C> where
    C::StateBackend: StateBackend<HashFor<Block>>, 

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

impl Send for Executor<'_>

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

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

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

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

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

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

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

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

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

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

impl Send for Condvar

impl Send for Runnable

impl<T: Send> Send for Task<T>

impl Send for AtomicWaker

impl<T> Send for BitPtrError<T> where
    T: BitStore

impl<T> Send for BitSpanError<T> where
    T: BitStore

impl<O, T> Send for Iter<'_, O, T> where
    O: BitOrder,
    T: BitStore

impl<O, T> Send for IterMut<'_, O, T> where
    O: BitOrder,
    T: BitStore

impl<O, T> Send for BitSlice<O, T> where
    O: BitOrder,
    T: BitStore + Sync

impl<O, T> Send for BitBox<O, T> where
    O: BitOrder,
    T: BitStore

impl<O, T> Send for Drain<'_, O, T> where
    O: BitOrder,
    T: BitStore

impl<O, T> Send for BitVec<O, T> where
    O: BitOrder,
    T: BitStore

impl Send for Bump

impl Send for Bytes

impl Send for BytesMut

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

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

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

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

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

impl Send for Select<'_>

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

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

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

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

impl Send for Collector

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

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

impl Send for Parker

impl Send for Unparker

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

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

impl Send for Event

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

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

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

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

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

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

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

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

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

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

impl<T> Send for Bucket<T>

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

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

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

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

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

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

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

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

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

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

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

impl<T: Send> Send for AtomicLazyCell<T>

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

impl<'a, T: Scalar + Send, R: Dim, C: Dim, RStride: Dim, CStride: Dim> Send for SliceStorage<'a, T, R, C, RStride, CStride>

impl<'a, T: Scalar + Send, R: Dim, C: Dim, RStride: Dim, CStride: Dim> Send for SliceStorageMut<'a, T, R, C, RStride, CStride>

impl<O, T: ?Sized> Send for OwningRef<O, T> where
    O: Send,
    for<'a> &'a T: Send

impl<O, T: ?Sized> Send for OwningRefMut<O, T> where
    O: Send,
    for<'a> &'a mut T: Send

impl<T> Send for SendWrapper<T>

impl Send for LockGuard

impl Send for Region

impl<'a> Send for BoundColumnFamily<'a>

impl<T: ThreadMode> Send for DBWithThreadMode<T>

impl<'a, D: DBAccess> Send for DBRawIteratorWithThreadMode<'a, D>

impl Send for Options

impl Send for ReadOptions

impl<'a> Send for DBPinnableSlice<'a>

impl<'a, D: DBAccess> Send for SnapshotWithThreadMode<'a, D>

impl<'a> Send for SstFileWriter<'a>

impl Send for WriteBatch

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

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

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

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

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

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

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

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

impl<'a> Send for MaybeUninitSlice<'a>

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

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

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

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

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

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

impl<T> Send for Empty<T>

impl<T> Send for Pending<T>

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

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

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

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

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

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

impl<T> Send for Lock<T> where
    T: Send

impl Send for Semaphore

impl Send for AtomicTask

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

impl<'a> Send for CCtx<'a>

impl Send for DCtx<'_>

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

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

Auto implementors

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

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

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

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

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

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

impl Send for Adler32

impl Send for Error

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

impl<Aes, NonceSize> Send for AesGcm<Aes, NonceSize> where
    Aes: Send,
    NonceSize: Send

impl Send for Aes128

impl Send for Aes192

impl Send for Aes256

impl Send for AHasher

impl Send for RandomState

impl<S> Send for AhoCorasick<S> where
    S: Send

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

impl<'a, 'b, S> Send for FindOverlappingIter<'a, 'b, S> where
    S: Send + Sync

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

impl Send for MatchKind

impl Send for Error

impl Send for ErrorKind

impl Send for MatchKind

impl Send for Config

impl Send for Builder

impl Send for Searcher

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

impl Send for Match

impl<C, P> Send for FullDeps<C, P> where
    C: Send + Sync,
    P: Send + Sync

impl Send for Executor

impl Send for SessionKeys

impl Send for BlockLength

impl Send for SS58Prefix

impl Send for Version

impl Send for MaxLocks

impl<C> Send for LinearWeightToFee<C> where
    C: Send

impl Send for Runtime

impl Send for Event

impl !Send for Origin

impl Send for PalletInfo

impl Send for Call

impl Send for RuntimeApi

impl Send for Characters

impl Send for ForWhat

impl<T, A, B> Send for AnagolayRecord<T, A, B> where
    A: Send,
    B: Send,
    T: Send

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

impl<T> Send for AnagolayArtifactStructure<T> where
    T: Send

impl<T> Send for AnagolayVersionData<T> where
    T: Send

impl<T> Send for Pallet<T> where
    T: Send

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

impl<T> Send for Call<T> where
    T: Send

impl Send for Prefix

impl Send for Infix

impl Send for Suffix

impl Send for Style

impl Send for Colour

impl<'a, S: ?Sized> Send for ANSIGenericString<'a, S> where
    S: Sync,
    <S as ToOwned>::Owned: Send

impl<'a, S: ?Sized> Send for ANSIGenericStrings<'a, S> where
    S: Sync,
    <S as ToOwned>::Owned: Sync

impl Send for Error

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

impl<A: ?Sized, B: ?Sized> Send for AbsDiff<A, B> where
    <A as AbsDiffEq<B>>::Epsilon: Send

impl<A: ?Sized, B: ?Sized> Send for Relative<A, B> where
    <A as AbsDiffEq<B>>::Epsilon: Send

impl<A: ?Sized, B: ?Sized> Send for Ulps<A, B> where
    <A as AbsDiffEq<B>>::Epsilon: Send

impl<T, const CAP: usize> Send for ArrayVec<T, CAP> where
    T: Send

impl<T, const CAP: usize> Send for IntoIter<T, CAP> where
    T: Send

impl<const CAP: usize> Send for ArrayString<CAP>

impl<T> Send for CapacityError<T> where
    T: Send

impl Send for DerTag

impl Send for DerLength

impl Send for DerValue

impl Send for DerObject

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

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

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

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

impl Send for RecvError

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

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

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

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

impl<T> Send for ReadableOwned<T> where
    T: Send + Sync

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

impl<T> Send for WritableOwned<T> where
    T: Send + Sync

impl Send for Timer

impl<T> Send for Async<T> where
    T: Send

impl Send for Barrier

impl Send for Semaphore

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

impl Send for Child

impl Send for ChildStdin

impl Send for ChildStdout

impl Send for ChildStderr

impl Send for Command

impl Send for Builder

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

impl Send for Task

impl Send for TaskId

impl<T> Send for LocalKey<T>

impl Send for AccessError

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

impl<S> Send for Cloned<S> where
    S: Send

impl<S> Send for Copied<S> where
    S: Send

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

impl<S> Send for Fuse<S> where
    S: Send

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

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

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

impl<S> Send for Skip<S> where
    S: Send

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

impl<S> Send for StepBy<S> where
    S: Send

impl<S> Send for Take<S> where
    S: Send

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

impl<A, B> Send for Zip<A, B> where
    A: Send,
    B: Send,
    <A as Stream>::Item: Send

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

impl<S> Send for Flatten<S> where
    S: Send,
    <<S as Stream>::Item as IntoStream>::IntoStream: Send

impl<S, U, F> Send for FlatMap<S, U, F> where
    F: Send,
    S: Send,
    U: Send

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

impl<T> Send for Empty<T> where
    T: Send

impl<F> Send for FromFn<F> where
    F: Send

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

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

impl<T> Send for Repeat<T> where
    T: Send

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

impl Send for Interval

impl<T> Send for Pending<T> where
    T: Send

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

impl<R> Send for Lines<R> where
    R: Send

impl<R> Send for Split<R> where
    R: Send

impl<T> Send for Bytes<T> where
    T: Send

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

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

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

impl<W> Send for BufWriter<W> where
    W: Send

impl<W> Send for IntoInnerError<W> where
    W: Send

impl<T> Send for Cursor<T> where
    T: Send

impl Send for Empty

impl Send for Repeat

impl Send for Sink

impl Send for Stderr

impl Send for Stdin

impl Send for Stdout

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

impl Send for UnixStream

impl Send for DirBuilder

impl Send for DirEntry

impl Send for File

impl Send for OpenOptions

impl Send for ReadDir

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

impl<'a> Send for Components<'a>

impl<'a> Send for Iter<'a>

impl Send for Path

impl Send for PathBuf

impl Send for TcpListener

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

impl Send for TcpStream

impl Send for UdpSocket

impl Send for BytesCodec

impl Send for LengthCodec

impl Send for LinesCodec

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

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

impl<T, D> Send for FramedRead<T, D> where
    D: Send,
    T: Send

impl<T, D> Send for FramedReadParts<T, D> where
    D: Send,
    T: Send

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

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

impl<T> Send for Atomic<T> where
    T: Send

impl Send for Stream

impl Send for Frame

impl !Send for Symbol

impl<'a> Send for SymbolName<'a>

impl<'a> Send for BytesOrWideString<'a>

impl<'a, 'b> !Send for BacktraceFmt<'a, 'b>

impl Send for PrintFmt

impl<'fmt, 'a, 'b> !Send for BacktraceFrameFmt<'fmt, 'a, 'b>

impl Send for Backtrace

impl<'a> Send for Base64Display<'a>

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

impl<W> Send for EncoderWriter<W> where
    W: Send

impl<S> Send for EncoderStringWriter<S> where
    S: Send

impl Send for DecodeError

impl Send for Config

impl Send for DecodeError

impl Send for BigEndian

impl Send for Config

impl Send for Bounded

impl Send for Infinite

impl<O, L> Send for WithOtherLimit<O, L> where
    L: Send,
    O: Send

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

impl<O, I> Send for WithOtherIntEncoding<O, I> where
    I: Send,
    O: Send

impl<O, T> Send for WithOtherTrailing<O, T> where
    O: Send,
    T: Send

impl<'storage> Send for SliceReader<'storage>

impl<R> Send for IoReader<R> where
    R: Send

impl<R, O> Send for Deserializer<R, O> where
    O: Send,
    R: Send

impl Send for ErrorKind

impl<W, O> Send for Serializer<W, O> where
    O: Send,
    W: Send

impl Send for ErrorKind

impl Send for Language

impl Send for Mnemonic

impl Send for Seed

impl Send for BitSafeU8

impl Send for BitSafeU16

impl Send for BitSafeU32

impl Send for BitSafeU64

impl<O, V> Send for IntoIter<O, V> where
    O: Send,
    V: Send

impl<O, V> Send for BitArray<O, V> where
    O: Send,
    V: Send

impl<'a, O, T> Send for BitDomain<'a, O, T> where
    T: Sync,
    <T as BitStore>::Unalias: Sync

impl<'a, O, T> Send for BitDomainMut<'a, O, T> where
    T: Sync,
    <T as BitStore>::Unalias: Sync

impl<'a, T> Send for Domain<'a, T> where
    T: Sync,
    <T as BitStore>::Unalias: Sync

impl<'a, T> Send for DomainMut<'a, T> where
    <T as BitStore>::Access: Sync,
    <T as BitStore>::Unalias: Send

impl<R> Send for BitIdx<R>

impl<R> Send for BitIdxError<R>

impl<R> Send for BitTail<R>

impl<R> Send for BitPos<R>

impl<R> Send for BitSel<R>

impl<R> Send for BitMask<R>

impl Send for Const

impl Send for Mut

impl Send for Lsb0

impl Send for Msb0

impl<M, O = Lsb0, T = usize> !Send for BitPtr<M, O, T>

impl<M, O = Lsb0, T = usize> !Send for BitPtrRange<M, O, T>

impl<'a, M, O = Lsb0, T = usize> !Send for BitRef<'a, M, O, T>

impl<M, T = usize> !Send for Address<M, T>

impl<T> !Send for AddressError<T>

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

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

impl<'a, O, T> Send for ChunksMut<'a, O, T> where
    <T as BitStore>::Alias: Sync

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

impl<'a, O, T> Send for ChunksExactMut<'a, O, T> where
    <T as BitStore>::Alias: Sync

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

impl<'a, O, T> Send for RChunksMut<'a, O, T> where
    <T as BitStore>::Alias: Sync

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

impl<'a, O, T> Send for RChunksExactMut<'a, O, T> where
    <T as BitStore>::Alias: Sync

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

impl<'a, O, T, P> Send for SplitMut<'a, O, T, P> where
    P: Send,
    <T as BitStore>::Alias: Sync

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

impl<'a, O, T, P> Send for RSplitMut<'a, O, T, P> where
    P: Send,
    <T as BitStore>::Alias: Sync

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

impl<'a, O, T, P> Send for SplitNMut<'a, O, T, P> where
    P: Send,
    <T as BitStore>::Alias: Sync

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

impl<'a, O, T, P> Send for RSplitNMut<'a, O, T, P> where
    P: Send,
    <T as BitStore>::Alias: Sync

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

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

impl<O, T> !Send for IntoIter<O, T>

impl<'a, O, T, I> Send for Splice<'a, O, T, I> where
    I: Send

impl Send for VarBlake2b

impl Send for Blake2b

impl Send for VarBlake2s

impl Send for Blake2s

impl Send for Blake2b

impl Send for Blake2s

impl<BlockSize> Send for BlockBuffer<BlockSize>

impl Send for PadError

impl Send for UnpadError

impl Send for ZeroPadding

impl Send for Pkcs7

impl Send for AnsiX923

impl Send for Iso7816

impl Send for NoPadding

impl<T> Send for Unblock<T> where
    T: Send

impl Send for Alphabet

impl Send for Error

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

impl Send for Error

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

impl Send for Error

impl Send for BStr

impl Send for BString

impl<'a> Send for Finder<'a>

impl<'a> Send for FinderReverse<'a>

impl<'a> Send for Find<'a>

impl<'a> Send for FindReverse<'a>

impl<'a> Send for Bytes<'a>

impl<'a> Send for Fields<'a>

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

impl<'a> Send for Split<'a>

impl<'a> Send for SplitReverse<'a>

impl<'a> Send for SplitN<'a>

impl<'a> Send for SplitNReverse<'a>

impl<'a> Send for Lines<'a>

impl<'a> Send for LinesWithTerminator<'a>

impl<'a> Send for DrainBytes<'a>

impl<B> Send for ByteLines<B> where
    B: Send

impl<B> Send for ByteRecords<B> where
    B: Send

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

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

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

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

impl Send for Utf8Error

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

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

impl Send for Error

impl Send for BigEndian

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

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

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

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

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

impl Send for UninitSlice

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

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

impl<R> Send for Cipher<R> where
    R: Send

impl Send for XChaCha20

impl<C> Send for ChaChaPoly1305<C> where
    C: Send

impl Send for FixedOffset

impl Send for Local

impl Send for Utc

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

impl Send for NaiveDate

impl Send for IsoWeek

impl Send for NaiveTime

impl Send for Parsed

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

impl Send for Pad

impl Send for Numeric

impl Send for Fixed

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

impl Send for ParseError

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

impl Send for Weekday

impl Send for Month

impl<const S: usize> Send for Cid<S>

impl Send for Error

impl Send for Version

impl Send for LoopError

impl Send for AppSettings

impl<'a, 'b> !Send for App<'a, 'b>

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

impl<'a> Send for ArgMatches<'a>

impl<'a> Send for Values<'a>

impl<'a> Send for OsValues<'a>

impl<'a> Send for ArgGroup<'a>

impl Send for ArgSettings

impl<'a> Send for SubCommand<'a>

impl Send for Shell

impl Send for ErrorKind

impl Send for Error

impl Send for PopError

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

impl Send for Case

impl Send for FromCasing

impl<T> Send for Cursor<T> where
    T: Send

impl Send for Error

impl Send for ErrorKind

impl Send for SeekFrom

impl<R> Send for Bytes<R> where
    R: Send

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

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

impl<'prev, 'subs> !Send for ArgScopeStack<'prev, 'subs>

impl Send for MangledName

impl Send for Encoding

impl Send for CloneSuffix

impl Send for Name

impl Send for NestedName

impl Send for Prefix

impl Send for SourceName

impl Send for TaggedName

impl Send for Identifier

impl Send for SeqId

impl Send for CallOffset

impl Send for NvOffset

impl Send for VOffset

impl Send for Type

impl Send for TypeHandle

impl Send for BuiltinType

impl Send for Decltype

impl Send for ArrayType

impl Send for VectorType

impl Send for TemplateArg

impl Send for MemberName

impl Send for Expression

impl Send for SimpleId

impl Send for ExprPrimary

impl Send for Initializer

impl Send for LocalName

impl Send for LambdaSig

impl Send for SpecialName

impl Send for Error

impl<T> Send for Symbol<T> where
    T: Send

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

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

impl<'a, K, V, C> Send for MapCursor<'a, K, V, C> where
    C: Sync,
    K: Send,
    V: Send

impl<'a, K, V> Send for MapIter<'a, K, V> where
    K: Send + Sync,
    V: Send + Sync

impl<K> Send for SetForest<K> where
    K: Send

impl<K> Send for Set<K> where
    K: Send

impl<'a, K, C> Send for SetCursor<'a, K, C> where
    C: Sync,
    K: Send

impl<'a, K> Send for SetIter<'a, K> where
    K: Send + Sync

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

impl Send for StackMap

impl Send for Reloc

impl Send for CodeInfo

impl<'a> Send for CFGPrinter<'a>

impl<'f> Send for FuncCursor<'f>

impl<'f> Send for EncCursor<'f>

impl Send for DataValue

impl<'a> Send for DisplayDataValues<'a>

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

impl<'a> Send for ChildIter<'a>

impl<'a> Send for PredIter<'a>

impl Send for AtomicRmwOp

impl<'f, IIB> Send for InsertBuilder<'f, IIB> where
    IIB: Send

impl<'f> Send for ReplaceBuilder<'f>

impl<'a> Send for Values<'a>

impl Send for ValueDef

impl<'a> Send for DisplayInst<'a>

impl Send for Block

impl Send for Value

impl Send for Inst

impl Send for StackSlot

impl Send for GlobalValue

impl Send for Constant

impl Send for Immediate

impl Send for JumpTable

impl Send for FuncRef

impl Send for SigRef

impl Send for Heap

impl Send for Table

impl Send for AnyEntity

impl Send for Signature

impl Send for AbiParam

impl Send for ExtFuncData

impl Send for Function

impl<'a> Send for DisplayFunction<'a>

impl<'a> Send for InstOffsetIter<'a>

impl Send for HeapData

impl Send for HeapStyle

impl Send for Imm64

impl Send for Uimm64

impl Send for Uimm32

impl Send for V128Imm

impl Send for Offset32

impl Send for Ieee32

impl Send for Ieee64

impl Send for Opcode

impl<'a> Send for BranchInfo<'a>

impl<'a> Send for CallInfo<'a>

impl Send for Layout

impl<'f> Send for Blocks<'f>

impl<'f> Send for Insts<'f>

impl Send for LibCall

impl Send for Endianness

impl Send for MemFlags

impl Send for SourceLoc

impl Send for StackSlots

impl Send for TableData

impl Send for TrapCode

impl Send for Type

impl Send for ValueLoc

impl Send for ArgumentLoc

impl Send for ValueLabel

impl Send for UnwindInfo

impl Send for UnwindInfo

impl<Reg> Send for UnwindCode<Reg> where
    Reg: Send

impl<Reg> Send for UnwindInfo<Reg> where
    Reg: Send

impl Send for UnwindInfo

impl Send for CallConv

impl Send for BranchRange

impl<'a> Send for Encodings<'a>

impl Send for Encoding

impl Send for EncInfo

impl Send for RegBank

impl Send for RegInfo

impl<'a> Send for DisplayRegUnit<'a>

impl Send for StackRef

impl Send for StackBase

impl Send for LookupError

impl Send for Builder

impl Send for Loop

impl Send for NonRegInput

impl<'func, I> !Send for Lower<'func, I>

impl<I> !Send for VCode<I>

impl<I> !Send for VCodeBuilder<I>

impl Send for ABIArg

impl Send for ArgsOrRets

impl Send for StackAMode

impl<M> Send for ABICalleeImpl<M> where
    M: Send,
    <M as ABIMachineSpec>::I: Send

impl<M> Send for ABICallerImpl<M> where
    M: Send

impl Send for CallDest

impl<I> Send for MachBuffer<I> where
    <I as MachInst>::LabelUse: Send

impl Send for MachLabel

impl Send for MachSrcLoc

impl Send for AtomicRmwOp

impl<R> Send for ValueRegs<R> where
    R: Send

impl<'a> Send for MachTerminator<'a>

impl<'a, Inst> Send for UnwindInfoContext<'a, Inst> where
    Inst: Sync

impl Send for Template

impl Send for Descriptor

impl Send for Detail

impl Send for Builder

impl Send for SetError

impl<'a> Send for PredicateView<'a>

impl Send for Flags

impl Send for Regalloc

impl Send for OptLevel

impl Send for TlsModel

impl<'a> Send for FlagsOrIsa<'a>

impl Send for TimingToken

impl Send for PassTimes

impl Send for PlainWriter

impl !Send for Context

impl Send for IntCC

impl Send for FloatCC

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

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

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

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

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

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

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

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

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

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

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

impl<'a> Send for FunctionBuilder<'a>

impl Send for Switch

impl Send for Variable

impl Send for WasmType

impl Send for WasmError

impl Send for ReturnMode

impl Send for Alias

impl Send for FuncIndex

impl Send for TableIndex

impl Send for GlobalIndex

impl Send for MemoryIndex

impl Send for DataIndex

impl Send for ElemIndex

impl Send for TypeIndex

impl Send for ModuleIndex

impl Send for EventIndex

impl Send for EntityIndex

impl Send for EntityType

impl Send for Global

impl Send for GlobalInit

impl Send for Table

impl Send for Memory

impl Send for Event

impl Send for Hasher

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

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

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

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

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

impl<T> Send for SendTimeoutError<T> where
    T: Send

impl Send for RecvError

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

impl<T> Send for Steal<T> where
    T: Send

impl<'g, T, P> !Send for CompareExchangeError<'g, T, P>

impl<T: ?Sized> Send for Owned<T> where
    T: Send

impl<'g, T> !Send for Shared<'g, T>

impl !Send for LocalHandle

impl !Send for Guard

impl Send for Backoff

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

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

impl Send for WaitGroup

impl<'env> Send for Scope<'env>

impl<'scope, 'env> Send for ScopedThreadBuilder<'scope, 'env>

impl Send for MacError

impl<M> Send for Output<M>

impl Send for CuckooError

impl<H> Send for CuckooFilter<H> where
    H: Send

impl Send for Scalar

impl Send for DecodeKind

impl Send for DecodeError

impl Send for BitOrder

impl Send for Encoding

impl Send for Translate

impl Send for Wrap

impl Send for BaseDirs

impl Send for UserDirs

impl Send for ProjectDirs

impl Send for BaseDirs

impl Send for UserDirs

impl Send for ProjectDirs

impl Send for Type

impl Send for QueryType

impl Send for Class

impl Send for QueryClass

impl Send for Opcode

impl<'a> Send for Packet<'a>

impl<'a> Send for Question<'a>

impl<'a> Send for ResourceRecord<'a>

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

impl Send for Error

impl Send for Header

impl Send for Builder

impl Send for Record

impl Send for Record

impl Send for Record

impl Send for Record

impl<'a> Send for Record<'a>

impl Send for Record

impl Send for Record

impl Send for Record

impl Send for Record

impl Send for Record

impl Send for Record

impl Send for Record

impl Send for Record

impl<'a> Send for Record<'a>

impl<'a> Send for Record<'a>

impl Send for Record

impl Send for Record

impl<'a> Send for Record<'a>

impl<'a> Send for Record<'a>

impl<'a> Send for Record<'a>

impl<'a> Send for Record<'a>

impl<'a> Send for Record<'a>

impl<'a> Send for RecordIter<'a>

impl Send for Record

impl<'a> Send for RData<'a>

impl Send for Signature

impl Send for Keypair

impl Send for PublicKey

impl Send for SecretKey

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

impl Send for Filter

impl Send for Builder

impl Send for Timestamp

impl !Send for Style

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

impl Send for Color

impl Send for Target

impl Send for WriteStyle

impl !Send for Formatter

impl<'a> Send for Env<'a>

impl Send for Logger

impl Send for Builder

impl Send for Error

impl Send for Errno

impl Send for Exit

impl Send for Signal

impl Send for Backtrace

impl<E> Send for Compat<E> where
    E: Send

impl<D> Send for Context<D>

impl<T> Send for SyncFailure<T> where
    T: Send

impl Send for Error

impl<'f> Send for Causes<'f>

impl Send for Rng

impl Send for Phase

impl<H, N> Send for State<H, N> where
    H: Send,
    N: Send

impl<Id, H, N> Send for RoundParams<Id, H, N> where
    H: Send,
    Id: Send,
    N: Send

impl<Id, H, N, Signature> Send for Round<Id, H, N, Signature> where
    H: Send,
    Id: Send,
    N: Send,
    Signature: Send

impl<H, N, V> Send for VoteGraph<H, N, V> where
    H: Send,
    N: Send,
    V: Send

impl<Id> Send for VoterSet<Id> where
    Id: Send

impl Send for VoterInfo

impl<Id> Send for RoundState<Id> where
    Id: Send

impl<Id> Send for VoterState<Id> where
    Id: Send

impl<H, N, S, Id> Send for CommunicationOut<H, N, S, Id> where
    H: Send,
    Id: Send,
    N: Send,
    S: Send

impl Send for GoodCommit

impl Send for BadCommit

impl Send for GoodCatchUp

impl Send for BadCatchUp

impl<O> Send for Callback<O>

impl<H, N, S, Id> Send for CommunicationIn<H, N, S, Id> where
    H: Send,
    Id: Send,
    N: Send,
    S: Send

impl<Id, Timer, Input, Output> Send for RoundData<Id, Timer, Input, Output> where
    Id: Send,
    Input: Send,
    Output: Send,
    Timer: Send

impl<H, N, E, GlobalIn, GlobalOut> Send for Voter<H, N, E, GlobalIn, GlobalOut> where
    E: Send + Sync,
    GlobalIn: Send,
    GlobalOut: Send,
    H: Send + Sync,
    N: Send + Sync,
    <E as Environment<H, N>>::Id: Send + Sync,
    <E as Environment<H, N>>::In: Send + Sync,
    <E as Environment<H, N>>::Out: Send + Sync,
    <E as Environment<H, N>>::Signature: Send + Sync,
    <E as Environment<H, N>>::Timer: Send + Sync

impl<H, N> Send for Prevote<H, N> where
    H: Send,
    N: Send

impl<H, N> Send for Precommit<H, N> where
    H: Send,
    N: Send

impl<H, N> Send for PrimaryPropose<H, N> where
    H: Send,
    N: Send

impl Send for Error

impl<Id, V, S> Send for Equivocation<Id, V, S> where
    Id: Send,
    S: Send,
    V: Send

impl<H, N> Send for Message<H, N> where
    H: Send,
    N: Send

impl<H, N, S, Id> Send for SignedMessage<H, N, S, Id> where
    H: Send,
    Id: Send,
    N: Send,
    S: Send

impl<H, N, S, Id> Send for Commit<H, N, S, Id> where
    H: Send,
    Id: Send,
    N: Send,
    S: Send

impl<H, N, S, Id> Send for SignedPrevote<H, N, S, Id> where
    H: Send,
    Id: Send,
    N: Send,
    S: Send

impl<H, N, S, Id> Send for SignedPrecommit<H, N, S, Id> where
    H: Send,
    Id: Send,
    N: Send,
    S: Send

impl<H, N, S, Id> Send for CompactCommit<H, N, S, Id> where
    H: Send,
    Id: Send,
    N: Send,
    S: Send

impl<H, N, S, Id> Send for CatchUp<H, N, S, Id> where
    H: Send,
    Id: Send,
    N: Send,
    S: Send

impl<H, N> Send for CommitValidationResult<H, N> where
    H: Send,
    N: Send

impl<H, N, S, Id> Send for HistoricalVotes<H, N, S, Id> where
    H: Send,
    Id: Send,
    N: Send,
    S: Send

impl Send for Crc

impl<R> Send for CrcReader<R> where
    R: Send

impl<W> Send for CrcWriter<W> where
    W: Send

impl<R> Send for DeflateEncoder<R> where
    R: Send

impl<R> Send for DeflateDecoder<R> where
    R: Send

impl<R> Send for DeflateEncoder<R> where
    R: Send

impl<R> Send for DeflateDecoder<R> where
    R: Send

impl<W> Send for DeflateEncoder<W> where
    W: Send

impl<W> Send for DeflateDecoder<W> where
    W: Send

impl<R> Send for GzEncoder<R> where
    R: Send

impl<R> Send for GzDecoder<R> where
    R: Send

impl<R> Send for MultiGzDecoder<R> where
    R: Send

impl<R> Send for GzEncoder<R> where
    R: Send

impl<R> Send for GzDecoder<R> where
    R: Send

impl<R> Send for MultiGzDecoder<R> where
    R: Send

impl<W> Send for GzEncoder<W> where
    W: Send

impl<W> Send for GzDecoder<W> where
    W: Send

impl Send for GzHeader

impl Send for GzBuilder

impl Send for Compress

impl Send for Decompress

impl Send for Status

impl<R> Send for ZlibEncoder<R> where
    R: Send

impl<R> Send for ZlibDecoder<R> where
    R: Send

impl<R> Send for ZlibEncoder<R> where
    R: Send

impl<R> Send for ZlibDecoder<R> where
    R: Send

impl<W> Send for ZlibEncoder<W> where
    W: Send

impl<W> Send for ZlibDecoder<W> where
    W: Send

impl Send for Compression

impl Send for FnvHasher

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

impl<V> Send for FinalizationResult<V> where
    V: Send

impl<H, N, V> Send for ForkTree<H, N, V> where
    H: Send,
    N: Send,
    V: Send

impl<'a> Send for Parse<'a>

impl<'a> Send for ParseIntoOwned<'a>

impl<'a> Send for ByteSerialize<'a>

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

impl Send for Analysis

impl<System, Block, Context, UnsignedValidator, AllModules, OnRuntimeUpgrade> Send for Executive<System, Block, Context, UnsignedValidator, AllModules, OnRuntimeUpgrade> where
    AllModules: Send,
    Block: Send,
    Context: Send,
    OnRuntimeUpgrade: Send,
    System: Send,
    UnsignedValidator: Send

impl<B, O> Send for DecodeDifferent<B, O> where
    B: Send,
    O: Send

impl<E> Send for FnEncode<E>

impl !Send for StopParse

impl<P> !Send for Braces<P>

impl<P> !Send for Brackets<P>

impl<P> !Send for Parens<P>

impl<P, T, V> Send for PunctuatedInner<P, T, V> where
    P: Send,
    T: Send,
    V: Send

impl Send for NoTrailing

impl Send for Trailing

impl !Send for Meta

impl Send for ForAll

impl Send for ForAny

impl<T, OverarchingCall> Send for SubmitTransaction<T, OverarchingCall> where
    OverarchingCall: Send,
    T: Send

impl<T, C, X> Send for Signer<T, C, X> where
    C: Send,
    X: Send,
    <T as SigningTypes>::Public: Send

impl<T> Send for Account<T> where
    <T as SigningTypes>::Public: Send

impl Send for BlockLength

impl<T> Send for CheckGenesis<T>

impl<T> Send for CheckMortality<T>

impl<T> Send for CheckNonce<T>

impl<T> Send for CheckSpecVersion<T>

impl<T> Send for CheckTxVersion<T>

impl<T> Send for CheckWeight<T>

impl<T> Send for SubstrateWeight<T> where
    T: Send

impl<T> Send for Pallet<T> where
    T: Send

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

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

impl<T> Send for Call<T> where
    T: Send

impl<T> Send for _GeneratedPrefixForStorageAccount<T> where
    T: Send

impl<T> Send for _GeneratedPrefixForStorageBlockHash<T> where
    T: Send

impl<T> Send for _GeneratedPrefixForStorageLastRuntimeUpgrade<T> where
    T: Send

impl Send for Phase

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

impl<AccountId> Send for RawOrigin<AccountId> where
    AccountId: Send

impl<Index, AccountData> Send for AccountInfo<Index, AccountData> where
    AccountData: Send,
    Index: Send

impl<AccountId> Send for EnsureRoot<AccountId> where
    AccountId: Send

impl<AccountId> Send for EnsureSigned<AccountId> where
    AccountId: Send

impl<Who, AccountId> Send for EnsureSignedBy<Who, AccountId> where
    AccountId: Send,
    Who: Send

impl<AccountId> Send for EnsureNone<AccountId> where
    AccountId: Send

impl<T> Send for EnsureNever<T> where
    T: Send

impl<AccountId, L, R> Send for EnsureOneOf<AccountId, L, R> where
    AccountId: Send,
    L: Send,
    R: Send

impl Send for InitKind

impl Send for RefStatus

impl Send for DecRefError

impl Send for IncRefError

impl<T> Send for Provider<T> where
    T: Send

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

impl<T> Send for ChainContext<T> where
    T: Send

impl<T> Send for Module<T> where
    T: Send

impl Send for FsStats

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

impl<T> Send for UnboundedSender<T> where
    T: Send

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

impl<T> Send for UnboundedReceiver<T> where
    T: Send

impl Send for SendError

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

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

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

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

impl Send for Canceled

impl<T> Send for DiagnoseFuture<T> where
    T: Send

impl<T> Send for DiagSpawn<T> where
    T: Send

impl !Send for LocalPool

impl !Send for LocalSpawner

impl<S> Send for BlockingStream<S> where
    S: Send

impl Send for ThreadPool

impl Send for Enter

impl Send for EnterError

impl<T> Send for Pending<T> where
    T: Send

impl<F> Send for PollOnce<F> where
    F: Send

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

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

impl Send for YieldNow

impl<F1, F2> Send for Zip<F1, F2> where
    F1: Send,
    F2: Send,
    <F1 as Future>::Output: Send,
    <F2 as Future>::Output: Send

impl<F1, F2> Send for TryZip<F1, F2> where
    F1: Send,
    F2: Send,
    <F1 as Future>::Output: Send,
    <F2 as Future>::Output: Send

impl<F1, F2> Send for Or<F1, F2> where
    F1: Send,
    F2: Send

impl<F1, F2> Send for Race<F1, F2> where
    F1: Send,
    F2: Send

impl<F> Send for CatchUnwind<F> where
    F: Send

impl<S> Send for BlockOn<S> where
    S: Send

impl<T> Send for Empty<T> where
    T: Send

impl<I> Send for Iter<I> where
    I: Send

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

impl<T> Send for Pending<T> where
    T: Send

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

impl<T> Send for Repeat<T> where
    T: Send

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

impl<T, F, Fut> Send for Unfold<T, F, Fut> where
    F: Send,
    Fut: Send,
    T: Send

impl<T, F, Fut> Send for TryUnfold<T, F, Fut> where
    F: Send,
    Fut: Send,
    T: Send

impl<'a, S: ?Sized> Send for NextFuture<'a, S> where
    S: Send

impl<'a, S: ?Sized> Send for TryNextFuture<'a, S> where
    S: Send

impl<S: ?Sized> Send for CountFuture<S> where
    S: Send

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

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

impl<S, P, B> Send for PartitionFuture<S, P, B> where
    B: Send,
    P: Send,
    S: Send

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

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

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

impl<S> Send for Fuse<S> where
    S: Send

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

impl<S, U, F> Send for FlatMap<S, U, F> where
    F: Send,
    S: Send,
    U: Send

impl<S> Send for Flatten<S> where
    S: Send,
    <S as Stream>::Item: Send

impl<S, F, Fut> Send for Then<S, F, Fut> where
    F: Send,
    Fut: Send,
    S: Send

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

impl<S1, S2> Send for Or<S1, S2> where
    S1: Send,
    S2: Send

impl<S1, S2> Send for Race<S1, S2> where
    S1: Send,
    S2: Send

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

impl<S> Send for Take<S> where
    S: Send

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

impl<S> Send for Skip<S> where
    S: Send

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

impl<S> Send for StepBy<S> where
    S: Send

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

impl<S> Send for Cloned<S> where
    S: Send

impl<S> Send for Copied<S> where
    S: Send

impl<S> Send for Cycle<S> where
    S: Send

impl<S> Send for Enumerate<S> where
    S: Send

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

impl<'a, S: ?Sized> Send for NthFuture<'a, S> where
    S: Send

impl<S> Send for LastFuture<S> where
    S: Send,
    <S as Stream>::Item: Send

impl<'a, S: ?Sized, P> Send for FindFuture<'a, S, P> where
    P: Send,
    S: Send

impl<'a, S: ?Sized, F> Send for FindMapFuture<'a, S, F> where
    F: Send,
    S: Send

impl<'a, S: ?Sized, P> Send for PositionFuture<'a, S, P> where
    P: Send,
    S: Send

impl<'a, S: ?Sized, P> Send for AllFuture<'a, S, P> where
    P: Send,
    S: Send

impl<'a, S: ?Sized, P> Send for AnyFuture<'a, S, P> where
    P: Send,
    S: Send

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

impl<'a, S: ?Sized, F> Send for TryForEachFuture<'a, S, F> where
    F: Send,
    S: Send

impl<A, B> Send for Zip<A, B> where
    A: Send,
    B: Send,
    <A as Stream>::Item: Send

impl<S, FromA, FromB> Send for UnzipFuture<S, FromA, FromB> where
    FromA: Send,
    FromB: Send,
    S: Send

impl<T> Send for AssertAsync<T> where
    T: Send

impl<T> Send for BlockOn<T> where
    T: Send

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

impl<W> Send for BufWriter<W> where
    W: Send

impl<T> Send for Cursor<T> where
    T: Send

impl Send for Empty

impl Send for Repeat

impl Send for Sink

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

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

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

impl<R> Send for Lines<R> where
    R: Send

impl<R> Send for Split<R> where
    R: Send

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

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

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

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

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

impl<R> Send for Take<R> where
    R: Send

impl<R> Send for Bytes<R> where
    R: Send

impl<R1, R2> Send for Chain<R1, R2> where
    R1: Send,
    R2: Send

impl<'a, S: ?Sized> Send for SeekFuture<'a, S> where
    S: Send

impl<'a, W: ?Sized> Send for WriteFuture<'a, W> where
    W: Send

impl<'a, W: ?Sized> Send for WriteVectoredFuture<'a, W> where
    W: Send

impl<'a, W: ?Sized> Send for WriteAllFuture<'a, W> where
    W: Send

impl<'a, W: ?Sized> Send for FlushFuture<'a, W> where
    W: Send

impl<'a, W: ?Sized> Send for CloseFuture<'a, W> where
    W: Send

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

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

impl<IO> Send for TlsStream<IO> where
    IO: Send

impl<IO> Send for TlsStream<IO> where
    IO: Send

impl Send for TlsAcceptor

impl<IO> Send for Connect<IO> where
    IO: Send

impl<IO> Send for Accept<IO> where
    IO: Send

impl<IO> Send for FailableConnect<IO> where
    IO: Send

impl<IO> Send for FailableAccept<IO> where
    IO: Send

impl<T> Send for TlsStream<T> where
    T: Send

impl Send for SpawnError

impl<'a> Send for WakerRef<'a>

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

impl Send for Delay

impl<Fut> Send for Fuse<Fut> where
    Fut: Send

impl<Fut> Send for CatchUnwind<Fut> where
    Fut: Send

impl<T> Send for RemoteHandle<T> where
    T: Send

impl<Fut> Send for Remote<Fut> where
    Fut: Send,
    <Fut as Future>::Output: Send

impl<Fut> Send for Shared<Fut> where
    Fut: Send,
    <Fut as Future>::Output: Send + Sync

impl<Fut> Send for WeakShared<Fut> where
    Fut: Send,
    <Fut as Future>::Output: Send + Sync

impl<F> Send for Flatten<F> where
    F: Send,
    <F as Future>::Output: Send

impl<F> Send for FlattenStream<F> where
    F: Send,
    <F as Future>::Output: Send

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

impl<F> Send for IntoStream<F> where
    F: Send

impl<Fut, T> Send for MapInto<Fut, T> where
    Fut: Send

impl<Fut1, Fut2, F> Send for Then<Fut1, Fut2, F> where
    F: Send,
    Fut1: Send,
    Fut2: Send

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

impl<Fut> Send for NeverError<Fut> where
    Fut: Send

impl<Fut> Send for UnitError<Fut> where
    Fut: Send

impl<Fut> Send for IntoFuture<Fut> where
    Fut: Send

impl<Fut1, Fut2> Send for TryFlatten<Fut1, Fut2> where
    Fut1: Send,
    Fut2: Send

impl<Fut> Send for TryFlattenStream<Fut> where
    Fut: Send,
    <Fut as TryFuture>::Ok: Send

impl<Fut, Si> Send for FlattenSink<Fut, Si> where
    Fut: Send,
    Si: Send

impl<Fut1, Fut2, F> Send for AndThen<Fut1, Fut2, F> where
    F: Send,
    Fut1: Send,
    Fut2: Send

impl<Fut1, Fut2, F> Send for OrElse<Fut1, Fut2, F> where
    F: Send,
    Fut1: Send,
    Fut2: Send

impl<Fut, E> Send for ErrInto<Fut, E> where
    Fut: Send

impl<Fut, E> Send for OkInto<Fut, E> where
    Fut: Send

impl<Fut, F> Send for InspectOk<Fut, F> where
    F: Send,
    Fut: Send

impl<Fut, F> Send for InspectErr<Fut, F> where
    F: Send,
    Fut: Send

impl<Fut, F> Send for MapOk<Fut, F> where
    F: Send,
    Fut: Send

impl<Fut, F> Send for MapErr<Fut, F> where
    F: Send,
    Fut: Send

impl<Fut, F, G> Send for MapOkOrElse<Fut, F, G> where
    F: Send,
    Fut: Send,
    G: Send

impl<Fut, F> Send for UnwrapOrElse<Fut, F> where
    F: Send,
    Fut: Send

impl<F> Send for Lazy<F> where
    F: Send

impl<T> Send for Pending<T> where
    T: Send

impl<Fut> Send for MaybeDone<Fut> where
    Fut: Send,
    <Fut as Future>::Output: Send

impl<Fut> Send for TryMaybeDone<Fut> where
    Fut: Send,
    <Fut as TryFuture>::Ok: Send

impl<F> Send for OptionFuture<F> where
    F: Send

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

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

impl<Fut1, Fut2> Send for Join<Fut1, Fut2> where
    Fut1: Send,
    Fut2: Send,
    <Fut1 as Future>::Output: Send,
    <Fut2 as Future>::Output: Send

impl<Fut1, Fut2, Fut3> Send for Join3<Fut1, Fut2, Fut3> where
    Fut1: Send,
    Fut2: Send,
    Fut3: Send,
    <Fut1 as Future>::Output: Send,
    <Fut2 as Future>::Output: Send,
    <Fut3 as Future>::Output: Send

impl<Fut1, Fut2, Fut3, Fut4> Send for Join4<Fut1, Fut2, Fut3, Fut4> where
    Fut1: Send,
    Fut2: Send,
    Fut3: Send,
    Fut4: Send,
    <Fut1 as Future>::Output: Send,
    <Fut2 as Future>::Output: Send,
    <Fut3 as Future>::Output: Send,
    <Fut4 as Future>::Output: Send

impl<Fut1, Fut2, Fut3, Fut4, Fut5> Send for Join5<Fut1, Fut2, Fut3, Fut4, Fut5> where
    Fut1: Send,
    Fut2: Send,
    Fut3: Send,
    Fut4: Send,
    Fut5: Send,
    <Fut1 as Future>::Output: Send,
    <Fut2 as Future>::Output: Send,
    <Fut3 as Future>::Output: Send,
    <Fut4 as Future>::Output: Send,
    <Fut5 as Future>::Output: Send

impl<F> Send for JoinAll<F> where
    F: Send,
    <F as Future>::Output: Send

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

impl<Fut> Send for SelectAll<Fut> where
    Fut: Send

impl<Fut1, Fut2> Send for TryJoin<Fut1, Fut2> where
    Fut1: Send,
    Fut2: Send,
    <Fut1 as TryFuture>::Ok: Send,
    <Fut2 as TryFuture>::Ok: Send

impl<Fut1, Fut2, Fut3> Send for TryJoin3<Fut1, Fut2, Fut3> where
    Fut1: Send,
    Fut2: Send,
    Fut3: Send,
    <Fut1 as TryFuture>::Ok: Send,
    <Fut2 as TryFuture>::Ok: Send,
    <Fut3 as TryFuture>::Ok: Send

impl<Fut1, Fut2, Fut3, Fut4> Send for TryJoin4<Fut1, Fut2, Fut3, Fut4> where
    Fut1: Send,
    Fut2: Send,
    Fut3: Send,
    Fut4: Send,
    <Fut1 as TryFuture>::Ok: Send,
    <Fut2 as TryFuture>::Ok: Send,
    <Fut3 as TryFuture>::Ok: Send,
    <Fut4 as TryFuture>::Ok: Send

impl<Fut1, Fut2, Fut3, Fut4, Fut5> Send for TryJoin5<Fut1, Fut2, Fut3, Fut4, Fut5> where
    Fut1: Send,
    Fut2: Send,
    Fut3: Send,
    Fut4: Send,
    Fut5: Send,
    <Fut1 as TryFuture>::Ok: Send,
    <Fut2 as TryFuture>::Ok: Send,
    <Fut3 as TryFuture>::Ok: Send,
    <Fut4 as TryFuture>::Ok: Send,
    <Fut5 as TryFuture>::Ok: Send

impl<F> Send for TryJoinAll<F> where
    F: Send,
    <F as TryFuture>::Ok: Send

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

impl<Fut> Send for SelectOk<Fut> where
    Fut: Send

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

impl Send for AbortHandle

impl<T> Send for Abortable<T> where
    T: Send

impl Send for Aborted

impl<St1, St2> Send for Chain<St1, St2> where
    St1: Send,
    St2: Send

impl<St, C> Send for Collect<St, C> where
    C: Send,
    St: Send

impl<St, FromA, FromB> Send for Unzip<St, FromA, FromB> where
    FromA: Send,
    FromB: Send,
    St: Send

impl<St> Send for Concat<St> where
    St: Send,
    <St as Stream>::Item: Send

impl<St> Send for Cycle<St> where
    St: Send

impl<St> Send for Enumerate<St> where
    St: Send

impl<St, Fut, F> Send for Filter<St, Fut, F> where
    F: Send,
    Fut: Send,
    St: Send,
    <St as Stream>::Item: Send

impl<St, Fut, F> Send for FilterMap<St, Fut, F> where
    F: Send,
    Fut: Send,
    St: Send

impl<St, Fut, T, F> Send for Fold<St, Fut, T, F> where
    F: Send,
    Fut: Send,
    St: Send,
    T: Send

impl<St, Fut, F> Send for ForEach<St, Fut, F> where
    F: Send,
    Fut: Send,
    St: Send

impl<St> Send for Fuse<St> where
    St: Send

impl<St> Send for StreamFuture<St> where
    St: Send

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

impl<'a, St: ?Sized> Send for Next<'a, St> where
    St: Send

impl<'a, St: ?Sized> Send for SelectNextSome<'a, St> where
    St: Send

impl<St> Send for Peekable<St> where
    St: Send,
    <St as Stream>::Item: Send

impl<'a, St> Send for Peek<'a, St> where
    St: Send,
    <St as Stream>::Item: Send

impl<'a, St, F> Send for NextIf<'a, St, F> where
    F: Send,
    St: Send,
    <St as Stream>::Item: Send

impl<'a, St, T: ?Sized> Send for NextIfEq<'a, St, T> where
    St: Send,
    T: Sync,
    <St as Stream>::Item: Send

impl<St> Send for Skip<St> where
    St: Send

impl<St, Fut, F> Send for SkipWhile<St, Fut, F> where
    F: Send,
    Fut: Send,
    St: Send,
    <St as Stream>::Item: Send

impl<St> Send for Take<St> where
    St: Send

impl<St, Fut, F> Send for TakeWhile<St, Fut, F> where
    F: Send,
    Fut: Send,
    St: Send,
    <St as Stream>::Item: Send

impl<St, Fut> Send for TakeUntil<St, Fut> where
    Fut: Send,
    St: Send,
    <Fut as Future>::Output: Send

impl<St, Fut, F> Send for Then<St, Fut, F> where
    F: Send,
    Fut: Send,
    St: Send

impl<St1, St2> Send for Zip<St1, St2> where
    St1: Send,
    St2: Send,
    <St1 as Stream>::Item: Send,
    <St2 as Stream>::Item: Send

impl<St> Send for Chunks<St> where
    St: Send,
    <St as Stream>::Item: Send

impl<St> Send for ReadyChunks<St> where
    St: Send,
    <St as Stream>::Item: Send

impl<St, S, Fut, F> Send for Scan<St, S, Fut, F> where
    F: Send,
    Fut: Send,
    S: Send,
    St: Send

impl<St> Send for BufferUnordered<St> where
    St: Send,
    <St as Stream>::Item: Send

impl<St> Send for Buffered<St> where
    St: Send,
    <St as Stream>::Item: Send,
    <<St as Stream>::Item as Future>::Output: Send

impl<St, Fut, F> Send for ForEachConcurrent<St, Fut, F> where
    F: Send,
    Fut: Send,
    St: Send

impl<S> Send for SplitStream<S> where
    S: Send

impl<S, Item> Send for SplitSink<S, Item> where
    Item: Send,
    S: Send

impl<T, Item> Send for ReuniteError<T, Item> where
    Item: Send,
    T: Send

impl<St> Send for CatchUnwind<St> where
    St: Send

impl<St> Send for Flatten<St> where
    St: Send,
    <St as Stream>::Item: Send

impl<St, Si> Send for Forward<St, Si> where
    Si: Send,
    St: Send,
    <St as TryStream>::Ok: Send

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

impl<St, U, F> Send for FlatMap<St, U, F> where
    F: Send,
    St: Send,
    U: Send

impl<St, Fut, F> Send for AndThen<St, Fut, F> where
    F: Send,
    Fut: Send,
    St: Send

impl<St> Send for IntoStream<St> where
    St: Send

impl<St, Fut, F> Send for OrElse<St, Fut, F> where
    F: Send,
    Fut: Send,
    St: Send

impl<'a, St: ?Sized> Send for TryNext<'a, St> where
    St: Send

impl<St, Fut, F> Send for TryForEach<St, Fut, F> where
    F: Send,
    Fut: Send,
    St: Send

impl<St, Fut, F> Send for TryFilter<St, Fut, F> where
    F: Send,
    Fut: Send,
    St: Send,
    <St as TryStream>::Ok: Send

impl<St, Fut, F> Send for TryFilterMap<St, Fut, F> where
    F: Send,
    Fut: Send,
    St: Send

impl<St> Send for TryFlatten<St> where
    St: Send,
    <St as TryStream>::Ok: Send

impl<St, C> Send for TryCollect<St, C> where
    C: Send,
    St: Send

impl<St> Send for TryConcat<St> where
    St: Send,
    <St as TryStream>::Ok: Send

impl<St> Send for TryChunks<St> where
    St: Send,
    <St as TryStream>::Ok: Send

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

impl<St, Fut, T, F> Send for TryFold<St, Fut, T, F> where
    F: Send,
    Fut: Send,
    St: Send,
    T: Send

impl<T, F, Fut> Send for TryUnfold<T, F, Fut> where
    F: Send,
    Fut: Send,
    T: Send

impl<St, Fut, F> Send for TrySkipWhile<St, Fut, F> where
    F: Send,
    Fut: Send,
    St: Send,
    <St as TryStream>::Ok: Send

impl<St, Fut, F> Send for TryTakeWhile<St, Fut, F> where
    F: Send,
    Fut: Send,
    St: Send,
    <St as TryStream>::Ok: Send

impl<St> Send for TryBufferUnordered<St> where
    St: Send,
    <St as TryStream>::Ok: Send

impl<St> Send for TryBuffered<St> where
    St: Send,
    <<St as TryStream>::Ok as TryFuture>::Error: Send,
    <St as TryStream>::Ok: Send,
    <<St as TryStream>::Ok as TryFuture>::Ok: Send

impl<St, Fut, F> Send for TryForEachConcurrent<St, Fut, F> where
    F: Send,
    Fut: Send,
    St: Send

impl<St> Send for IntoAsyncRead<St> where
    St: Send,
    <St as TryStream>::Ok: Send

impl<St, E> Send for ErrInto<St, E> where
    St: Send

impl<St, F> Send for InspectOk<St, F> where
    F: Send,
    St: Send

impl<St, F> Send for InspectErr<St, F> where
    F: Send,
    St: Send

impl<St, F> Send for MapOk<St, F> where
    F: Send,
    St: Send

impl<St, F> Send for MapErr<St, F> where
    F: Send,
    St: Send

impl<I> Send for Iter<I> where
    I: Send

impl<T> Send for Repeat<T> where
    T: Send

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

impl<T> Send for Empty<T> where
    T: Send

impl<Fut> Send for Once<Fut> where
    Fut: Send

impl<T> Send for Pending<T> where
    T: Send

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

impl<St1, St2> Send for Select<St1, St2> where
    St1: Send,
    St2: Send

impl Send for PollNext

impl<St1, St2, Clos, State> Send for SelectWithStrategy<St1, St2, Clos, State> where
    Clos: Send,
    St1: Send,
    St2: Send,
    State: Send

impl<T, F, Fut> Send for Unfold<T, F, Fut> where
    F: Send,
    Fut: Send,
    T: Send

impl<T> Send for FuturesOrdered<T> where
    T: Send,
    <T as Future>::Output: Send

impl<'a, Fut> Send for IterMut<'a, Fut> where
    Fut: Send

impl<'a, Fut> Send for Iter<'a, Fut> where
    Fut: Send

impl<St> Send for SelectAll<St> where
    St: Send

impl<'a, St> Send for Iter<'a, St> where
    St: Send

impl<'a, St> Send for IterMut<'a, St> where
    St: Send

impl<St> Send for IntoIter<St> where
    St: Send

impl<'a, Si: ?Sized, Item> Send for Close<'a, Si, Item> where
    Si: Send

impl<T> Send for Drain<T> where
    T: Send

impl<Si1, Si2> Send for Fanout<Si1, Si2> where
    Si1: Send,
    Si2: Send

impl<'a, Si: ?Sized, Item> Send for Feed<'a, Si, Item> where
    Item: Send,
    Si: Send

impl<'a, Si: ?Sized, Item> Send for Flush<'a, Si, Item> where
    Si: Send

impl<Si, Item, E> Send for SinkErrInto<Si, Item, E> where
    Si: Send

impl<Si, F> Send for SinkMapErr<Si, F> where
    F: Send,
    Si: Send

impl<'a, Si: ?Sized, Item> Send for Send<'a, Si, Item> where
    Item: Send,
    Si: Send

impl<'a, Si: ?Sized, St: ?Sized> Send for SendAll<'a, Si, St> where
    Si: Send,
    St: Send,
    <St as TryStream>::Ok: Send

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

impl<Si, Item, U, Fut, F> Send for With<Si, Item, U, Fut, F> where
    F: Send,
    Fut: Send,
    Si: Send

impl<Si, Item, U, St, F> Send for WithFlatMap<Si, Item, U, St, F> where
    F: Send,
    Item: Send,
    Si: Send,
    St: Send

impl<Si, Item> Send for Buffer<Si, Item> where
    Item: Send,
    Si: Send

impl<Ex> Send for Executor01As03<Ex> where
    Ex: Send

impl<T> Send for Compat01As03<T> where
    T: Send

impl<S, SinkItem> Send for Compat01As03Sink<S, SinkItem> where
    S: Send,
    SinkItem: Send

impl<T> Send for Compat<T> where
    T: Send

impl<T, Item> Send for CompatSink<T, Item> where
    T: Send

impl<T> Send for AllowStdIo<T> where
    T: Send

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

impl<W> Send for BufWriter<W> where
    W: Send

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

impl<'a, W: ?Sized> Send for Close<'a, W> where
    W: Send

impl<'a, R, W: ?Sized> Send for Copy<'a, R, W> where
    R: Send,
    W: Send

impl<'a, R, W: ?Sized> Send for CopyBuf<'a, R, W> where
    R: Send,
    W: Send

impl<T> Send for Cursor<T> where
    T: Send

impl Send for Empty

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

impl<'a, W: ?Sized> Send for Flush<'a, W> where
    W: Send

impl<W, Item> Send for IntoSink<W, Item> where
    Item: Send,
    W: Send

impl<R> Send for Lines<R> where
    R: Send

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

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

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

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

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

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

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

impl Send for Repeat

impl<'a, S: ?Sized> Send for Seek<'a, S> where
    S: Send

impl Send for Sink

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

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

impl<T> Send for ReuniteError<T> where
    T: Send

impl<R> Send for Take<R> where
    R: Send

impl<T> Send for Window<T> where
    T: Send

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

impl<'a, W: ?Sized> Send for WriteVectored<'a, W> where
    W: Send

impl<'a, W: ?Sized> Send for WriteAll<'a, W> where
    W: Send

impl<T> Send for BiLock<T> where
    T: Send

impl<T> Send for ReuniteError<T> where
    T: Send

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

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

impl<T, N> Send for GenericArrayIter<T, N> where
    T: Send

impl Send for Error

impl Send for GHash

impl Send for Format

impl Send for Encoding

impl Send for Register

impl<T> Send for DebugAbbrevOffset<T> where
    T: Send

impl<T> Send for DebugAddrBase<T> where
    T: Send

impl<T> Send for DebugAddrIndex<T> where
    T: Send

impl<T> Send for DebugArangesOffset<T> where
    T: Send

impl<T> Send for DebugInfoOffset<T> where
    T: Send

impl<T> Send for DebugLineOffset<T> where
    T: Send

impl<T> Send for DebugLineStrOffset<T> where
    T: Send

impl<T> Send for LocationListsOffset<T> where
    T: Send

impl<T> Send for DebugLocListsBase<T> where
    T: Send

impl<T> Send for DebugLocListsIndex<T> where
    T: Send

impl<T> Send for DebugMacinfoOffset<T> where
    T: Send

impl<T> Send for DebugMacroOffset<T> where
    T: Send

impl<T> Send for RawRangeListsOffset<T> where
    T: Send

impl<T> Send for RangeListsOffset<T> where
    T: Send

impl<T> Send for DebugRngListsBase<T> where
    T: Send

impl<T> Send for DebugRngListsIndex<T> where
    T: Send

impl<T> Send for DebugStrOffset<T> where
    T: Send

impl<T> Send for DebugStrOffsetsBase<T> where
    T: Send

impl<T> Send for DebugStrOffsetsIndex<T> where
    T: Send

impl<T> Send for DebugTypesOffset<T> where
    T: Send

impl<T> Send for DebugFrameOffset<T> where
    T: Send

impl<T> Send for EhFrameOffset<T> where
    T: Send

impl<T> Send for UnitSectionOffset<T> where
    T: Send

impl Send for SectionId

impl Send for DwoId

impl Send for Arm

impl Send for X86

impl Send for X86_64

impl Send for DwUt

impl Send for DwCfa

impl Send for DwChildren

impl Send for DwTag

impl Send for DwAt

impl Send for DwForm

impl Send for DwAte

impl Send for DwLle

impl Send for DwDs

impl Send for DwEnd

impl Send for DwAccess

impl Send for DwVis

impl Send for DwLang

impl Send for DwAddr

impl Send for DwId

impl Send for DwCc

impl Send for DwInl

impl Send for DwOrd

impl Send for DwDsc

impl Send for DwIdx

impl Send for DwDefaulted

impl Send for DwLns

impl Send for DwLne

impl Send for DwLnct

impl Send for DwMacro

impl Send for DwRle

impl Send for DwOp

impl Send for DwEhPe

impl Send for BigEndian

impl<R> Send for DebugAddr<R> where
    R: Send

impl<R> Send for DebugFrame<R> where
    R: Send

impl<R> Send for EhFrameHdr<R> where
    R: Send

impl<R> Send for ParsedEhFrameHdr<R> where
    R: Send

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

impl<R> Send for EhFrame<R> where
    R: Send

impl<'bases, Section, R> Send for CfiEntriesIter<'bases, Section, R> where
    R: Send,
    Section: Send

impl<'bases, Section, R> Send for CieOrFde<'bases, Section, R> where
    R: Send,
    Section: Send,
    <R as Reader>::Offset: Send,
    <Section as UnwindSection<R>>::Offset: Send

impl<R, Offset> Send for CommonInformationEntry<R, Offset> where
    Offset: Send,
    R: Send

impl<'bases, Section, R> Send for PartialFrameDescriptionEntry<'bases, Section, R> where
    R: Send,
    Section: Send,
    <R as Reader>::Offset: Send,
    <Section as UnwindSection<R>>::Offset: Send

impl<R, Offset> Send for FrameDescriptionEntry<R, Offset> where
    Offset: Send,
    R: Send

impl<R> Send for UninitializedUnwindContext<R> where
    R: Send

impl<R> Send for UnwindContext<R> where
    R: Send

impl<'a, 'ctx, R> Send for UnwindTable<'a, 'ctx, R> where
    R: Send + Sync

impl<'iter, R> Send for RegisterRuleIter<'iter, R> where
    R: Sync

impl<R> Send for UnwindTableRow<R> where
    R: Send

impl<R> Send for CfaRule<R> where
    R: Send

impl<R> Send for RegisterRule<R> where
    R: Send

impl<R> Send for CallFrameInstruction<R> where
    R: Send

impl<'a, R> Send for CallFrameInstructionIter<'a, R> where
    R: Send + Sync

impl Send for Pointer

impl<R> Send for Dwarf<R> where
    R: Send + Sync

impl<R, Offset> Send for Unit<R, Offset> where
    Offset: Send,
    R: Send

impl<R> Send for RangeIter<R> where
    R: Send,
    <R as Reader>::Offset: Send

impl<'input, Endian> Send for EndianSlice<'input, Endian> where
    Endian: Send

impl<R> Send for DebugAbbrev<R> where
    R: Send

impl<R> Send for DebugAranges<R> where
    R: Send

impl<R> Send for ArangeHeaderIter<R> where
    R: Send,
    <R as Reader>::Offset: Send

impl<R, Offset> Send for ArangeHeader<R, Offset> where
    Offset: Send,
    R: Send

impl<R> Send for ArangeEntryIter<R> where
    R: Send

impl Send for ArangeEntry

impl<R> Send for DebugLine<R> where
    R: Send

impl<R, Program, Offset> Send for LineRows<R, Program, Offset> where
    Program: Send,
    R: Send

impl<R, Offset> Send for LineInstruction<R, Offset> where
    Offset: Send,
    R: Send

impl<R> Send for LineInstructions<R> where
    R: Send

impl Send for LineRow

impl Send for ColumnType

impl<R> Send for LineSequence<R> where
    R: Send

impl<R, Offset> Send for LineProgramHeader<R, Offset> where
    Offset: Send,
    R: Send

impl<R, Offset> Send for IncompleteLineProgram<R, Offset> where
    Offset: Send,
    R: Send

impl<R, Offset> Send for CompleteLineProgram<R, Offset> where
    Offset: Send,
    R: Send

impl<R, Offset> Send for FileEntry<R, Offset> where
    Offset: Send,
    R: Send

impl<R> Send for DebugLoc<R> where
    R: Send

impl<R> Send for DebugLocLists<R> where
    R: Send

impl<R> Send for LocationLists<R> where
    R: Send

impl<R> Send for RawLocListIter<R> where
    R: Send

impl<R> Send for RawLocListEntry<R> where
    R: Send,
    <R as Reader>::Offset: Send

impl<R> Send for LocListIter<R> where
    R: Send,
    <R as Reader>::Offset: Send

impl<R> Send for LocationListEntry<R> where
    R: Send

impl<T> Send for DieReference<T> where
    T: Send

impl<R, Offset> Send for Operation<R, Offset> where
    Offset: Send,
    R: Send

impl<R, Offset> Send for Location<R, Offset> where
    Offset: Send,
    R: Send

impl<R, Offset> Send for Piece<R, Offset> where
    Offset: Send,
    R: Send

impl<R> Send for EvaluationResult<R> where
    R: Send,
    <R as Reader>::Offset: Send

impl<R> Send for Expression<R> where
    R: Send

impl<R> Send for OperationIter<R> where
    R: Send

impl<R> Send for Evaluation<R> where
    R: Send,
    <R as Reader>::Offset: Send

impl<R> Send for PubNamesEntry<R> where
    R: Send,
    <R as Reader>::Offset: Send

impl<R> Send for DebugPubNames<R> where
    R: Send,
    <R as Reader>::Offset: Send

impl<R> Send for PubNamesEntryIter<R> where
    R: Send,
    <R as Reader>::Offset: Send

impl<R> Send for PubTypesEntry<R> where
    R: Send,
    <R as Reader>::Offset: Send

impl<R> Send for DebugPubTypes<R> where
    R: Send,
    <R as Reader>::Offset: Send

impl<R> Send for PubTypesEntryIter<R> where
    R: Send,
    <R as Reader>::Offset: Send

impl<R> Send for DebugRanges<R> where
    R: Send

impl<R> Send for DebugRngLists<R> where
    R: Send

impl<R> Send for RangeLists<R> where
    R: Send

impl<R> Send for RawRngListIter<R> where
    R: Send

impl<T> Send for RawRngListEntry<T> where
    T: Send

impl<R> Send for RngListIter<R> where
    R: Send,
    <R as Reader>::Offset: Send

impl Send for Range

impl<R> Send for DebugStr<R> where
    R: Send

impl<R> Send for DebugStrOffsets<R> where
    R: Send

impl<R> Send for DebugLineStr<R> where
    R: Send

impl<T> Send for UnitOffset<T> where
    T: Send

impl<R> Send for DebugInfo<R> where
    R: Send

impl<R> Send for DebugInfoUnitHeadersIter<R> where
    R: Send,
    <R as Reader>::Offset: Send

impl<Offset> Send for UnitType<Offset> where
    Offset: Send

impl<R, Offset> Send for UnitHeader<R, Offset> where
    Offset: Send,
    R: Send

impl<'abbrev, 'unit, R, Offset> Send for DebuggingInformationEntry<'abbrev, 'unit, R, Offset> where
    Offset: Send + Sync,
    R: Send + Sync

impl<R, Offset> Send for AttributeValue<R, Offset> where
    Offset: Send,
    R: Send

impl<R> Send for Attribute<R> where
    R: Send,
    <R as Reader>::Offset: Send

impl<'abbrev, 'entry, 'unit, R> !Send for AttrsIter<'abbrev, 'entry, 'unit, R>

impl<'abbrev, 'unit, R> Send for EntriesRaw<'abbrev, 'unit, R> where
    R: Send + Sync,
    <R as Reader>::Offset: Sync

impl<'abbrev, 'unit, R> Send for EntriesCursor<'abbrev, 'unit, R> where
    R: Send + Sync,
    <R as Reader>::Offset: Send + Sync

impl<'abbrev, 'unit, R> Send for EntriesTree<'abbrev, 'unit, R> where
    R: Send + Sync,
    <R as Reader>::Offset: Send + Sync

impl<'abbrev, 'unit, 'tree, R> Send for EntriesTreeNode<'abbrev, 'unit, 'tree, R> where
    R: Send + Sync,
    <R as Reader>::Offset: Send + Sync

impl<'abbrev, 'unit, 'tree, R> Send for EntriesTreeIter<'abbrev, 'unit, 'tree, R> where
    R: Send + Sync,
    <R as Reader>::Offset: Send + Sync

impl<R> Send for DebugTypes<R> where
    R: Send

impl<R> Send for DebugTypesUnitHeadersIter<R> where
    R: Send,
    <R as Reader>::Offset: Send

impl Send for ValueType

impl Send for Value

impl Send for Error

impl Send for Glob

impl Send for GlobMatcher

impl<'a> Send for GlobBuilder<'a>

impl Send for Error

impl Send for ErrorKind

impl Send for GlobSet

impl<'a> Send for Candidate<'a>

impl Send for Error

impl Send for Reason

impl<B> Send for SendRequest<B> where
    B: Send

impl<B> Send for ReadySendRequest<B> where
    B: Send

impl<T, B> Send for Connection<T, B> where
    B: Send,
    T: Send

impl Send for PushPromise

impl Send for Builder

impl<T, B> Send for Handshake<T, B> where
    B: Send,
    T: Send

impl<T, B> Send for Connection<T, B> where
    B: Send,
    T: Send

impl Send for Builder

impl<B> Send for SendResponse<B> where
    B: Send

impl<B> Send for SendPushedResponse<B> where
    B: Send

impl<B> Send for SendStream<B> where
    B: Send

impl Send for StreamId

impl Send for RecvStream

impl Send for FlowControl

impl Send for PingPong

impl Send for Ping

impl Send for Pong

impl<'reg> Send for BlockParams<'reg>

impl<'reg> Send for BlockContext<'reg>

impl Send for Context

impl Send for RenderError

impl Send for Path

impl<'reg, 'rc> Send for ScopedJson<'reg, 'rc>

impl<'reg, 'rc> Send for PathAndJson<'reg, 'rc>

impl<'reg> Send for Registry<'reg>

impl<'reg, 'rc> !Send for RenderContext<'reg, 'rc>

impl<'reg, 'rc> Send for Helper<'reg, 'rc>

impl<'reg, 'rc> Send for Decorator<'reg, 'rc>

impl Send for Template

impl Send for BlockParam

impl Send for Parameter

impl<T> Send for RawIter<T>

impl<'a, T, A = Global> !Send for RawIterHash<'a, T, A>

impl<K, V, S, A> Send for HashMap<K, V, S, A> where
    K: Send,
    S: Send,
    V: Send

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

impl<K, V, A> Send for IntoIter<K, V, A> where
    K: Send,
    V: Send

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

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

impl<'a, K, V, A> Send for Drain<'a, K, V, A> where
    A: Copy,
    K: Send,
    V: Send

impl<'a, K, V, F, A> Send for DrainFilter<'a, K, V, F, A> where
    F: Send,
    K: Send,
    V: Send

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

impl<'a, K, V, S, A> Send for RawEntryBuilderMut<'a, K, V, S, A> where
    K: Send,
    S: Send,
    V: Send

impl<'a, K, V, S, A> Send for RawEntryMut<'a, K, V, S, A> where
    A: Send,
    K: Send,
    S: Sync,
    V: Send

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

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

impl<'a, K, V, S, A> Send for Entry<'a, K, V, S, A> where
    A: Send,
    K: Send,
    S: Send,
    V: Send

impl<'a, K, V, S, A> Send for VacantEntry<'a, K, V, S, A> where
    K: Send,
    S: Send,
    V: Send

impl<'a, K, V, S, A> Send for OccupiedError<'a, K, V, S, A> where
    A: Send,
    K: Send,
    S: Send,
    V: Send

impl<T, S, A> Send for HashSet<T, S, A> where
    S: Send,
    T: Send

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

impl<K, A> Send for IntoIter<K, A> where
    K: Send

impl<'a, K, A> Send for Drain<'a, K, A> where
    A: Copy,
    K: Send

impl<'a, K, F, A> Send for DrainFilter<'a, K, F, A> where
    F: Send,
    K: Send

impl<'a, T, S, A> Send for Intersection<'a, T, S, A> where
    S: Sync,
    T: Sync

impl<'a, T, S, A> Send for Difference<'a, T, S, A> where
    S: Sync,
    T: Sync

impl<'a, T, S, A> Send for SymmetricDifference<'a, T, S, A> where
    S: Sync,
    T: Sync

impl<'a, T, S, A> Send for Union<'a, T, S, A> where
    S: Sync,
    T: Sync

impl<T> Send for HexFmt<T> where
    T: Send

impl<T> Send for HexList<T> where
    T: Send

impl<D> Send for Hmac<D> where
    D: Send

impl<D> Send for HmacDRBG<D>

impl<T> Send for HeaderMap<T> where
    T: Send

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

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

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

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

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

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

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

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

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

impl Send for HeaderName

impl Send for HeaderValue

impl Send for ToStrError

impl Send for Method

impl<T> Send for Request<T> where
    T: Send

impl Send for Parts

impl Send for Builder

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

impl Send for Parts

impl Send for Builder

impl Send for StatusCode

impl Send for Authority

impl Send for Builder

impl<T> Send for Port<T> where
    T: Send

impl Send for Scheme

impl Send for Uri

impl Send for Parts

impl Send for InvalidUri

impl Send for Version

impl Send for Error

impl Send for Extensions

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

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

impl Send for SizeHint

impl Send for Error

impl<T> Send for Status<T> where
    T: Send

impl<'headers, 'buf> Send for Request<'headers, 'buf>

impl<'headers, 'buf> Send for Response<'headers, 'buf>

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

impl Send for HttpDate

impl Send for Error

impl Send for Error

impl Send for Duration

impl Send for Timestamp

impl Send for Error

impl Send for Body

impl Send for Sender

impl<B> Send for SendRequest<B> where
    B: Send

impl<T, B> Send for Connection<T, B> where
    B: Send,
    <B as Body>::Data: Send

impl Send for Builder

impl<T> Send for Parts<T> where
    T: Send

impl Send for Name

impl Send for GaiResolver

impl Send for GaiAddrs

impl Send for GaiFuture

impl<R> Send for HttpConnector<R> where
    R: Send

impl Send for HttpInfo

impl Send for Connected

impl<C, B, T> Send for Connect<C, B, T> where
    C: Send

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

impl Send for Builder

impl Send for Error

impl Send for AddrStream

impl<E> Send for Http<E> where
    E: Send

impl<I, F, E> Send for Connecting<I, F, E> where
    E: Send,
    F: Send,
    I: Send

impl<T, S, E> Send for Connection<T, S, E> where
    E: Send,
    S: Send,
    T: Send,
    <<S as HttpService<Body>>::ResBody as Body>::Data: Send,
    <S as HttpService<Body>>::Future: Send,
    <S as HttpService<Body>>::ResBody: Send

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

impl<I, S, E> Send for Server<I, S, E> where
    E: Send,
    I: Send,
    S: Send

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

impl Send for Upgraded

impl Send for OnUpgrade

impl<T> Send for Parts<T> where
    T: Send

impl<T> Send for HttpsConnector<T> where
    T: Send

impl<T> Send for MaybeHttpsStream<T> where
    T: Send

impl Send for Idna

impl Send for Config

impl Send for Errors

impl Send for IfEvent

impl Send for IfWatcher

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

impl<'a, T, S1, S2> Send for SymmetricDifference<'a, T, S1, S2> where
    S1: Sync,
    S2: Sync,
    T: Sync

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

impl Send for Interval

impl Send for IoVec

impl Send for IpNetwork

impl Send for Ipv4Network

impl Send for Ipv6Network

impl Send for IpAddrRange

impl Send for IpNet

impl Send for Ipv4Net

impl Send for Ipv6Net

impl Send for IpSubnets

impl Send for Ipv4Subnets

impl Send for Ipv6Subnets

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

impl<I, J> Send for Interleave<I, J> where
    I: Send,
    J: Send

impl<I, J> Send for InterleaveShortest<I, J> where
    I: Send,
    J: Send

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

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

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

impl<I, R> Send for MapInto<I, R> where
    I: Send

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

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

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

impl<I> Send for WhileSome<I> where
    I: Send

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

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

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

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

impl<I> Send for Step<I> where
    I: Send

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

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

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

impl<I, J> Send for ConsTuples<I, J> where
    I: Send

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

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

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

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

impl<'a, I> !Send for Chunk<'a, I>

impl<'a, I> !Send for Chunks<'a, I>

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

impl<'a, K, I, F> !Send for Group<'a, K, I, F>

impl<'a, K, I, F> !Send for Groups<'a, K, I, F>

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

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

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

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

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

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

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

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

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

impl<I> !Send for RcIter<I>

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

impl<F> Send for RepeatCall<F> where
    F: Send

impl<St, F> Send for Unfold<St, F> where
    F: Send,
    St: Send

impl<St, F> Send for Iterate<St, F> where
    F: Send,
    St: Send

impl<I> !Send for Tee<I>

impl<T> Send for TupleBuffer<T> where
    <T as TupleCollect>::Buffer: Send

impl<I, T> Send for TupleWindows<I, T> where
    I: Send,
    T: Send

impl<I, T> Send for Tuples<I, T> where
    I: Send,
    <T as TupleCollect>::Buffer: Send

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

impl<I, V, F> Send for UniqueBy<I, V, F> where
    F: Send,
    I: Send,
    V: Send

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

impl<I, J> Send for ZipEq<I, J> where
    I: Send,
    J: Send

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

impl<T> Send for Zip<T> where
    T: Send

impl<A, B> Send for EitherOrBoth<A, B> where
    A: Send,
    B: 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<T> Send for MinMaxResult<T> where
    T: Send

impl<T> Send for Position<T> where
    T: Send

impl<T> Send for FoldWhile<T> where
    T: Send

impl Send for Buffer

impl !Send for CompileError

impl !Send for Instance

impl !Send for LinkError

impl !Send for RuntimeError

impl !Send for Module

impl !Send for Table

impl !Send for Global

impl !Send for Memory

impl !Send for Collator

impl !Send for NumberFormat

impl !Send for PluralRules

impl !Send for Array

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

impl !Send for ArrayBuffer

impl !Send for Boolean

impl !Send for DataView

impl !Send for Error

impl !Send for EvalError

impl !Send for Function

impl !Send for Generator

impl !Send for Map

impl !Send for Iterator

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

impl !Send for IntoIter

impl !Send for IteratorNext

impl !Send for Number

impl !Send for Date

impl !Send for Object

impl !Send for Proxy

impl !Send for RangeError

impl !Send for RegExp

impl !Send for Set

impl !Send for SyntaxError

impl !Send for TypeError

impl !Send for UriError

impl !Send for WeakMap

impl !Send for WeakSet

impl !Send for JsString

impl !Send for Symbol

impl !Send for Promise

impl !Send for Int8Array

impl !Send for Int16Array

impl !Send for Int32Array

impl !Send for Uint8Array

impl !Send for Uint16Array

impl !Send for Uint32Array

impl !Send for Float32Array

impl !Send for Float64Array

impl<TSink, TStream> Send for Duplex<TSink, TStream> where
    TSink: Send,
    TStream: Send

impl<THandler, TMetadata> Send for LocalRpc<THandler, TMetadata> where
    THandler: Send,
    TMetadata: Send

impl Send for RpcError

impl Send for RpcChannel

impl Send for RpcFuture

impl<T> Send for TypedSubscriptionStream<T> where
    T: Send

impl Send for RawClient

impl Send for TypedClient

impl<T> Send for RemoteProcedure<T>

impl<T, S> Send for MetaIoHandler<T, S>

impl<M> Send for IoHandler<M>

impl<T, M> Send for IoDelegate<T, M>

impl Send for Noop

impl Send for ErrorCode

impl Send for Error

impl Send for Id

impl Send for Params

impl Send for MethodCall

impl Send for Call

impl Send for Request

impl Send for Success

impl Send for Failure

impl Send for Output

impl Send for Response

impl Send for Version

impl<M, S> Send for ServerHandler<M, S>

impl Send for Response

impl<M, S> Send for Rpc<M, S>

impl<M, S> Send for WeakRpc<M, S>

impl Send for RestApi

impl<M, S> Send for ServerBuilder<M, S>

impl Send for CloseHandle

impl Send for Server

impl<'a> Send for RequestContext<'a>

impl<M, S> Send for ServerBuilder<M, S>

impl Send for Server

impl Send for CloseHandle

impl<T, M> Send for IoDelegate<T, M>

impl<T, S> Send for PubSubHandler<T, S>

impl<I> Send for SubscriptionManager<I> where
    I: Send

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

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

impl Send for Session

impl Send for Sink

impl Send for Subscriber

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

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

impl Send for Origin

impl<T> Send for AllowCors<T> where
    T: Send

impl Send for Port

impl Send for Host

impl<T> Send for DomainsValidation<T> where
    T: Send

impl Send for Executor

impl Send for Separator

impl Send for StreamCodec

impl<S> Send for SuspendableStream<S> where
    S: Send

impl Send for Error

impl Send for Server

impl Send for CloseHandle

impl Send for Broadcaster

impl<M, S> Send for ServerBuilder<M, S>

impl Send for Kind

impl Send for IoStats

impl Send for DBOp

impl Send for InMemory

impl Send for Database

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

impl Send for Error

impl Send for statvfs

impl Send for max_align_t

impl Send for sigaction

impl Send for statfs

impl Send for flock

impl Send for flock64

impl Send for siginfo_t

impl !Send for stack_t

impl Send for stat

impl Send for stat64

impl Send for statfs64

impl Send for statvfs64

impl !Send for user

impl !Send for mcontext_t

impl Send for ipc_perm

impl Send for shmid_ds

impl Send for termios2

impl Send for ip_mreqn

impl !Send for ucontext_t

impl Send for sigset_t

impl Send for sysinfo

impl Send for msqid_ds

impl Send for semid_ds

impl Send for sem_t

impl Send for statx

impl !Send for aiocb

impl Send for __timeval

impl !Send for glob64_t

impl !Send for msghdr

impl Send for cmsghdr

impl Send for termios

impl Send for mallinfo

impl Send for mallinfo2

impl Send for nlmsghdr

impl Send for nlmsgerr

impl Send for nl_pktinfo

impl Send for nl_mmap_req

impl Send for nl_mmap_hdr

impl Send for nlattr

impl !Send for rtentry

impl Send for timex

impl Send for ntptimeval

impl !Send for regex_t

impl Send for Elf64_Chdr

impl Send for Elf32_Chdr

impl Send for seminfo

impl Send for utmpx

impl Send for fpos64_t

impl Send for rlimit64

impl !Send for glob_t

impl !Send for passwd

impl !Send for spwd

impl Send for dqblk

impl Send for itimerspec

impl Send for fsid_t

impl Send for packet_mreq

impl Send for cpu_set_t

impl !Send for if_nameindex

impl Send for msginfo

impl Send for sembuf

impl Send for input_event

impl Send for input_id

impl Send for input_mask

impl Send for ff_replay

impl Send for ff_trigger

impl Send for ff_envelope

impl Send for ff_effect

impl !Send for dl_phdr_info

impl Send for Elf32_Ehdr

impl Send for Elf64_Ehdr

impl Send for Elf32_Sym

impl Send for Elf64_Sym

impl Send for Elf32_Phdr

impl Send for Elf64_Phdr

impl Send for Elf32_Shdr

impl Send for Elf64_Shdr

impl Send for ucred

impl !Send for mntent

impl Send for genlmsghdr

impl Send for in6_pktinfo

impl Send for sockaddr_vm

impl Send for regmatch_t

impl Send for can_filter

impl Send for sock_filter

impl !Send for sock_fprog

impl Send for sockaddr_nl

impl Send for dirent

impl Send for dirent64

impl Send for af_alg_iv

impl Send for mq_attr

impl Send for can_frame

impl Send for canfd_frame

impl Send for timezone

impl Send for in_addr

impl Send for ip_mreq

impl Send for sockaddr

impl Send for sockaddr_in

impl !Send for addrinfo

impl Send for sockaddr_ll

impl Send for fd_set

impl !Send for tm

impl Send for sched_param

impl !Send for Dl_info

impl !Send for lconv

impl Send for in_pktinfo

impl !Send for ifaddrs

impl Send for in6_rtmsg

impl Send for arpreq

impl Send for arpreq_old

impl Send for arphdr

impl !Send for mmsghdr

impl Send for epoll_event

impl Send for sockaddr_un

impl Send for utsname

impl !Send for sigevent

impl Send for in6_addr

impl Send for DIR

impl !Send for group

impl Send for utimbuf

impl Send for timeval

impl Send for timespec

impl Send for rlimit

impl Send for rusage

impl Send for ipv6_mreq

impl !Send for hostent

impl !Send for iovec

impl Send for pollfd

impl Send for winsize

impl Send for linger

impl !Send for sigval

impl Send for itimerval

impl Send for tms

impl !Send for servent

impl !Send for protoent

impl Send for FILE

impl Send for fpos_t

impl<TInner> Send for BandwidthLogging<TInner> where
    TInner: Send

impl<TInner> Send for BandwidthListener<TInner> where
    TInner: Send

impl<TInner> Send for BandwidthFuture<TInner> where
    TInner: Send

impl<TInner> Send for BandwidthConnecLogging<TInner> where
    TInner: Send

impl<F> Send for SimpleProtocol<F> where
    F: Send + Sync

impl Send for PeerId

impl<THandlerErr> Send for ConnectionError<THandlerErr> where
    THandlerErr: Send

impl<TTransErr> Send for PendingConnectionError<TTransErr> where
    TTransErr: Send

impl<TOutboundOpenInfo, TCustom> Send for ConnectionHandlerEvent<TOutboundOpenInfo, TCustom> where
    TCustom: Send,
    TOutboundOpenInfo: Send

impl<TTrans> Send for ListenersStream<TTrans> where
    TTrans: Send,
    <TTrans as Transport>::Listener: Send

impl Send for ListenerId

impl<TTrans> Send for ListenersEvent<TTrans> where
    <TTrans as Transport>::Error: Send,
    <TTrans as Transport>::ListenerUpgrade: Send

impl<TDialInfo> Send for SubstreamEndpoint<TDialInfo> where
    TDialInfo: Send

impl<TMuxer> Send for Close<TMuxer> where
    TMuxer: Send + Sync

impl<'a, TInEvent> Send for PendingConnection<'a, TInEvent> where
    TInEvent: Send

impl<'a, TInEvent> Send for EstablishedConnection<'a, TInEvent> where
    TInEvent: Send

impl<'a, I, TInEvent, TOutEvent, THandler, TTransErr, THandlerErr> Send for EstablishedConnectionIter<'a, I, TInEvent, TOutEvent, THandler, TTransErr, THandlerErr> where
    I: Send,
    THandler: Send,
    THandlerErr: Send,
    TInEvent: Send,
    TOutEvent: Send,
    TTransErr: Send

impl Send for Endpoint

impl Send for Connected

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

impl<TMuxer, THandler> Send for Connection<TMuxer, THandler> where
    THandler: Send,
    TMuxer: Send + Sync,
    <THandler as ConnectionHandler>::OutboundOpenInfo: Send,
    <TMuxer as StreamMuxer>::OutboundSubstream: Send

impl<'a> Send for IncomingInfo<'a>

impl<'a> Send for OutgoingInfo<'a>

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

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

impl<A, B> Send for EitherOutbound<A, B> where
    <A as StreamMuxer>::OutboundSubstream: Send,
    <B as StreamMuxer>::OutboundSubstream: Send

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

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

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

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

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

impl Send for Keypair

impl Send for PublicKey

impl Send for SecretKey

impl Send for Keypair

impl Send for PublicKey

impl Send for Keypair

impl Send for SecretKey

impl Send for PublicKey

impl Send for Keypair

impl Send for PublicKey

impl<TSocket> Send for SingletonMuxer<TSocket> where
    TSocket: Send

impl<T> Send for StreamMuxerEvent<T> where
    T: Send

impl<P> Send for OutboundSubstreamRefWrapFuture<P> where
    P: Send,
    <<P as Deref>::Target as StreamMuxer>::OutboundSubstream: Send

impl<P> Send for OutboundSubstreamRefFuture<P> where
    P: Send,
    <<P as Deref>::Target as StreamMuxer>::OutboundSubstream: Send

impl<P> Send for SubstreamRef<P> where
    P: Send,
    <<P as Deref>::Target as StreamMuxer>::Substream: Send

impl<'a, TTrans, TInEvent, TOutEvent, THandler> Send for NetworkEvent<'a, TTrans, TInEvent, TOutEvent, THandler> where
    TInEvent: Send,
    TOutEvent: Send,
    <TTrans as Transport>::Error: Send,
    <<THandler as IntoConnectionHandler>::Handler as ConnectionHandler>::Error: Send,
    <TTrans as Transport>::ListenerUpgrade: Send

impl<TUpgrade> Send for IncomingConnection<TUpgrade> where
    TUpgrade: Send

impl<'a, TTrans, TInEvent, TOutEvent, THandler> Send for Peer<'a, TTrans, TInEvent, TOutEvent, THandler> where
    THandler: Send,
    TInEvent: Send,
    TOutEvent: Send,
    TTrans: Send,
    <TTrans as Transport>::Error: Send,
    <<THandler as IntoConnectionHandler>::Handler as ConnectionHandler>::Error: Send,
    <TTrans as Transport>::Listener: Send

impl<'a, TTrans, TInEvent, TOutEvent, THandler> Send for ConnectedPeer<'a, TTrans, TInEvent, TOutEvent, THandler> where
    THandler: Send,
    TInEvent: Send,
    TOutEvent: Send,
    TTrans: Send,
    <TTrans as Transport>::Error: Send,
    <<THandler as IntoConnectionHandler>::Handler as ConnectionHandler>::Error: Send,
    <TTrans as Transport>::Listener: Send

impl<'a, TTrans, TInEvent, TOutEvent, THandler> Send for DialingPeer<'a, TTrans, TInEvent, TOutEvent, THandler> where
    THandler: Send,
    TInEvent: Send,
    TOutEvent: Send,
    TTrans: Send,
    <TTrans as Transport>::Error: Send,
    <<THandler as IntoConnectionHandler>::Handler as ConnectionHandler>::Error: Send,
    <TTrans as Transport>::Listener: Send

impl<'a, TTrans, TInEvent, TOutEvent, THandler> Send for DisconnectedPeer<'a, TTrans, TInEvent, TOutEvent, THandler> where
    THandler: Send,
    TInEvent: Send,
    TOutEvent: Send,
    TTrans: Send,
    <TTrans as Transport>::Error: Send,
    <<THandler as IntoConnectionHandler>::Handler as ConnectionHandler>::Error: Send,
    <TTrans as Transport>::Listener: Send

impl<'a, TInEvent> Send for DialingAttempt<'a, TInEvent> where
    TInEvent: Send

impl<'a, TInEvent, TOutEvent, THandler, TTransErr, THandlerErr> Send for DialingAttemptIter<'a, TInEvent, TOutEvent, THandler, TTransErr, THandlerErr> where
    THandler: Send,
    THandlerErr: Send,
    TInEvent: Send,
    TOutEvent: Send,
    TTransErr: Send

impl<TTrans, TInEvent, TOutEvent, THandler> Send for Network<TTrans, TInEvent, TOutEvent, THandler> where
    THandler: Send,
    TInEvent: Send,
    TOutEvent: Send,
    TTrans: Send,
    <TTrans as Transport>::Error: Send,
    <<THandler as IntoConnectionHandler>::Handler as ConnectionHandler>::Error: Send,
    <TTrans as Transport>::Listener: Send

impl Send for NetworkInfo

impl<T, C> Send for AndThen<T, C> where
    C: Send,
    T: Send

impl<TListener, TMap> Send for AndThenStream<TListener, TMap> where
    TListener: Send,
    TMap: Send

impl<TFut, TMap, TMapOut> Send for AndThenFuture<TFut, TMap, TMapOut> where
    TFut: Send,
    TMap: Send,
    TMapOut: Send

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

impl<TOut> Send for DummyTransport<TOut> where
    TOut: Send

impl Send for DummyStream

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

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

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

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

impl<T, F> Send for MapErrListener<T, F> where
    F: Send,
    <T as Transport>::Listener: Send

impl<T, F> Send for MapErrListenerUpgrade<T, F> where
    F: Send,
    <T as Transport>::ListenerUpgrade: Send

impl<T, F> Send for MapErrDial<T, F> where
    F: Send,
    <T as Transport>::Dial: Send

impl Send for DialFuture

impl Send for Listener

impl<T> Send for Chan<T> where
    T: Send

impl<InnerTrans> Send for TransportTimeout<InnerTrans> where
    InnerTrans: Send

impl<InnerStream> Send for TimeoutListener<InnerStream> where
    InnerStream: Send

impl<InnerFut> Send for Timeout<InnerFut> where
    InnerFut: Send

impl<TErr> Send for TransportTimeoutError<TErr> where
    TErr: Send

impl<T> Send for Builder<T> where
    T: Send

impl<C, U> Send for Authenticate<C, U> where
    C: Send,
    U: Send,
    <U as InboundUpgrade<Negotiated<C>>>::Future: Send,
    <U as OutboundUpgrade<Negotiated<C>>>::Future: Send,
    <U as UpgradeInfo>::Info: Send,
    <<U as UpgradeInfo>::InfoIter as IntoIterator>::IntoIter: Send

impl<C, U> Send for Multiplex<C, U> where
    C: Send,
    U: Send,
    <U as InboundUpgrade<Negotiated<C>>>::Future: Send,
    <U as OutboundUpgrade<Negotiated<C>>>::Future: Send,
    <U as UpgradeInfo>::Info: Send,
    <<U as UpgradeInfo>::InfoIter as IntoIterator>::IntoIter: Send

impl<T> Send for Authenticated<T> where
    T: Send

impl<T> Send for Multiplexed<T> where
    T: Send

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

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

impl<F, U, C> Send for DialUpgradeFuture<F, U, C> where
    C: Send,
    F: Send,
    U: Send,
    <U as OutboundUpgrade<Negotiated<C>>>::Future: Send,
    <U as UpgradeInfo>::Info: Send,
    <<U as UpgradeInfo>::InfoIter as IntoIterator>::IntoIter: Send

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

impl<F, U, C> Send for ListenerUpgradeFuture<F, U, C> where
    C: Send,
    F: Send,
    U: Send,
    <U as InboundUpgrade<Negotiated<C>>>::Future: Send,
    <U as UpgradeInfo>::Info: Send

impl<O> Send for Boxed<O>

impl<T> Send for OptionalTransport<T> where
    T: Send

impl<TUpgr, TErr> Send for ListenerEvent<TUpgr, TErr> where
    TErr: Send,
    TUpgr: Send

impl<TErr> Send for TransportError<TErr> where
    TErr: Send

impl<C, U> Send for InboundUpgradeApply<C, U> where
    C: Send,
    U: Send,
    <U as InboundUpgrade<Negotiated<C>>>::Future: Send,
    <U as UpgradeInfo>::Info: Send

impl<C, U> Send for OutboundUpgradeApply<C, U> where
    C: Send,
    U: Send,
    <U as OutboundUpgrade<Negotiated<C>>>::Future: Send,
    <U as UpgradeInfo>::Info: Send,
    <<U as UpgradeInfo>::InfoIter as IntoIterator>::IntoIter: Send

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

impl<E> Send for UpgradeError<E> where
    E: Send

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

impl<U, F> Send for MapInboundUpgrade<U, F> where
    F: Send,
    U: Send

impl<U, F> Send for MapOutboundUpgrade<U, F> where
    F: Send,
    U: Send

impl<U, F> Send for MapInboundUpgradeErr<U, F> where
    F: Send,
    U: Send

impl<U, F> Send for MapOutboundUpgradeErr<U, F> where
    F: Send,
    U: Send

impl<T> Send for OptionalUpgrade<T> where
    T: Send

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

impl<S> Send for DeflateOutput<S> where
    S: Send

impl<T> Send for DnsConfig<T> where
    T: Send

impl<TErr> Send for DnsErr<TErr> where
    TErr: Send

impl Send for FloodsubRpc

impl Send for Floodsub

impl Send for Topic

impl Send for ProtocolId

impl<D, F> Send for Gossipsub<D, F> where
    D: Send,
    F: Send

impl<T> Send for MaxCountSubscriptionFilter<T> where
    T: Send

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

impl<T> Send for CallbackSubscriptionFilter<T> where
    T: Send

impl<Key, Value> Send for TimeCache<Key, Value> where
    Key: Send,
    Value: Send

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

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

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

impl<Key> Send for DuplicateCache<Key> where
    Key: Send

impl Send for TopicHash

impl<H> Send for Topic<H> where
    H: Send

impl Send for MessageId

impl Send for Identify

impl<T> Send for KademliaHandlerProto<T> where
    T: Send

impl<TUserData> Send for KademliaHandler<TUserData> where
    TUserData: Send

impl<TUserData> Send for KademliaHandlerEvent<TUserData> where
    TUserData: Send

impl<TUserData> Send for KademliaHandlerIn<TUserData> where
    TUserData: Send

impl Send for NodeStatus

impl<TKey, TVal> Send for Node<TKey, TVal> where
    TKey: Send,
    TVal: Send

impl<TKey> Send for InsertResult<TKey> where
    TKey: Send

impl<TKey, TVal> Send for AppliedPending<TKey, TVal> where
    TKey: Send,
    TVal: Send

impl<'a, TPeerId, TVal> Send for EntryRefView<'a, TPeerId, TVal> where
    TPeerId: Sync,
    TVal: Sync

impl<'a, TKey, TVal> Send for NodeRefView<'a, TKey, TVal> where
    TKey: Sync,
    TVal: Sync

impl<TKey, TVal> Send for EntryView<TKey, TVal> where
    TKey: Send,
    TVal: Send

impl<'a, TPeerId, TVal> Send for Entry<'a, TPeerId, TVal> where
    TPeerId: Send + Sync,
    TVal: Send

impl<'a, TKey, TVal> Send for PresentEntry<'a, TKey, TVal> where
    TKey: Send + Sync,
    TVal: Send

impl<'a, TKey, TVal> Send for PendingEntry<'a, TKey, TVal> where
    TKey: Send + Sync,
    TVal: Send

impl<'a, TKey, TVal> Send for AbsentEntry<'a, TKey, TVal> where
    TKey: Send + Sync,
    TVal: Send

impl<T> Send for Key<T> where
    T: Send

impl Send for KeyBytes

impl Send for Distance

impl<TKey, TVal> Send for KBucketsTable<TKey, TVal> where
    TKey: Send,
    TVal: Send

impl<'a, TKey, TVal> Send for KBucketRef<'a, TKey, TVal> where
    TKey: Send,
    TVal: Send

impl Send for KadPeer

impl Send for MemoryStore

impl Send for Error

impl Send for Key

impl Send for Record

impl Send for Addresses

impl<TStore> Send for Kademlia<TStore> where
    TStore: Send

impl Send for Quorum

impl Send for PeerRecord

impl Send for QueryResult

impl Send for GetRecordOk

impl Send for PutRecordOk

impl Send for BootstrapOk

impl Send for QueryInfo

impl<'a> Send for QueryMut<'a>

impl<'a> Send for QueryRef<'a>

impl Send for QueryId

impl Send for QueryStats

impl Send for Mdns

impl Send for MdnsEvent

impl Send for MdnsService

impl Send for MdnsPacket

impl Send for MdnsQuery

impl Send for MdnsPeer

impl Send for MplexConfig

impl<C> Send for Multiplex<C> where
    C: Send

impl Send for Substream

impl Send for NoiseError

impl<C> Send for RemoteIdentity<C> where
    C: Send

impl<T, C> Send for Handshake<T, C>

impl<T> Send for NoiseOutput<T> where
    T: Send

impl Send for X25519

impl Send for X25519Spec

impl Send for IK

impl Send for IX

impl Send for XX

impl<T> Send for Keypair<T> where
    T: Send

impl<T> Send for AuthenticKeypair<T> where
    T: Send

impl<T> Send for SecretKey<T> where
    T: Send

impl<T> Send for PublicKey<T> where
    T: Send

impl<P, C, R> Send for NoiseConfig<P, C, R> where
    C: Send,
    P: Send,
    R: Send

impl<P, C, R> Send for NoiseAuthenticated<P, C, R> where
    C: Send,
    P: Send,
    R: Send

impl Send for Ping

impl Send for PingConfig

impl Send for PingSuccess

impl Send for PingFailure

impl Send for PingHandler

impl Send for Ping

impl Send for PingEvent

impl<S> Send for PlainTextOutput<S> where
    S: Send

impl Send for Fingerprint

impl Send for PnetConfig

impl<S> Send for PnetOutput<S> where
    S: Send

impl Send for PnetError

impl<TCodec> Send for ResponseProtocol<TCodec> where
    TCodec: Send

impl<TCodec> Send for RequestProtocol<TCodec> where
    TCodec: Send

impl<C> Send for Throttled<C>

impl<Req, Res, CRes> Send for Event<Req, Res, CRes> where
    CRes: Send,
    Req: Send,
    Res: Send

impl<TRequest, TResponse, TChannelResponse> Send for RequestResponseMessage<TRequest, TResponse, TChannelResponse> where
    TChannelResponse: Send,
    TRequest: Send,
    TResponse: Send

impl<TRequest, TResponse, TChannelResponse> Send for RequestResponseEvent<TRequest, TResponse, TChannelResponse> where
    TChannelResponse: Send,
    TRequest: Send,
    TResponse: Send

impl<TResponse> Send for ResponseChannel<TResponse> where
    TResponse: Send

impl Send for RequestId

impl<TCodec> Send for RequestResponse<TCodec> where
    TCodec: Send

impl<TInEvent, TOutEvent> Send for NetworkBehaviourAction<TInEvent, TOutEvent> where
    TInEvent: Send,
    TOutEvent: Send

impl<TProtoHandler, TNewIn, TMap> Send for MapInEvent<TProtoHandler, TNewIn, TMap> where
    TMap: Send,
    TNewIn: Send,
    TProtoHandler: Send

impl<TProtoHandler, TMap> Send for MapOutEvent<TProtoHandler, TMap> where
    TMap: Send,
    TProtoHandler: Send

impl<TIntoProtoHandler> Send for NodeHandlerWrapperBuilder<TIntoProtoHandler> where
    TIntoProtoHandler: Send

impl<TProtoHandler> Send for NodeHandlerWrapper<TProtoHandler>

impl<TErr> Send for NodeHandlerWrapperError<TErr> where
    TErr: Send

impl<TInbound, TOutbound, TEvent> Send for OneShotHandler<TInbound, TOutbound, TEvent> where
    TEvent: Send,
    TInbound: Send

impl<TProto1, TProto2> Send for IntoProtocolsHandlerSelect<TProto1, TProto2> where
    TProto1: Send,
    TProto2: Send

impl<TProto1, TProto2> Send for ProtocolsHandlerSelect<TProto1, TProto2> where
    TProto1: Send,
    TProto2: Send

impl<K, H> Send for MultiHandler<K, H> where
    H: Send,
    K: Send

impl<K, H> Send for IntoMultiHandler<K, H> where
    H: Send,
    K: Send

impl<H> Send for IndexedProtoName<H> where
    H: Send

impl<K, I> Send for Info<K, I> where
    I: Send,
    K: Send

impl<K, H> Send for Upgrade<K, H> where
    H: Send,
    K: Send

impl<TUpgrade, TInfo> Send for SubstreamProtocol<TUpgrade, TInfo> where
    TInfo: Send,
    TUpgrade: Send

impl<TConnectionUpgrade, TOutboundOpenInfo, TCustom, TErr> Send for ProtocolsHandlerEvent<TConnectionUpgrade, TOutboundOpenInfo, TCustom, TErr> where
    TConnectionUpgrade: Send,
    TCustom: Send,
    TErr: Send,
    TOutboundOpenInfo: Send

impl<TUpgrErr> Send for ProtocolsHandlerUpgrErr<TUpgrErr> where
    TUpgrErr: Send

impl Send for KeepAlive

impl<TBehaviour> Send for Toggle<TBehaviour> where
    TBehaviour: Send

impl<TInner> Send for ToggleIntoProtoHandler<TInner> where
    TInner: Send

impl<TInner> Send for ToggleProtoHandler<TInner> where
    TInner: Send

impl<TBvEv, THandleErr> Send for SwarmEvent<TBvEv, THandleErr> where
    TBvEv: Send,
    THandleErr: Send

impl<TBehaviour, TInEvent, TOutEvent, THandler> Send for ExpandedSwarm<TBehaviour, TInEvent, TOutEvent, THandler> where
    TBehaviour: Send,
    TInEvent: Send,
    TOutEvent: Send

impl<'a> Send for SwarmPollParameters<'a>

impl<TBehaviour> Send for SwarmBuilder<TBehaviour> where
    TBehaviour: Send

impl Send for DialError

impl Send for Tcp

impl<T> Send for GenTcpConfig<T> where
    T: Send

impl<T> Send for TcpListenStream<T>

impl Send for UdsConfig

impl !Send for Transport

impl !Send for Connection

impl !Send for ListenEvent

impl Send for Dial

impl Send for Listen

impl Send for Connection

impl Send for JsErr

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

impl<T> Send for WsConfig<T> where
    T: Send

impl<T> Send for Connection<T> where
    T: Send

impl Send for Config

impl Send for PrivateKey

impl Send for Certificate

impl Send for Builder

impl Send for Error

impl<T> Send for WsConfig<T> where
    T: Send

impl<T> Send for BytesConnection<T> where
    T: Send

impl<S> Send for Yamux<S> where
    S: Send

impl Send for YamuxConfig

impl Send for YamuxError

impl<T> Send for Incoming<T> where
    T: Send

impl<T> !Send for LocalIncoming<T>

impl Send for __fsid_t

impl Send for rocksdb_t

impl !Send for gz_header

impl !Send for z_stream

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

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

impl<'a, K, V, S = RandomState> !Send for Entry<'a, K, V, S>

impl<'a, K, V, S = RandomState> !Send for OccupiedEntry<'a, K, V, S>

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

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

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

impl<K> Send for IntoIter<K> where
    K: Send

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

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

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

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

impl Send for Error

impl<'a> Send for RegressionData<'a>

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

impl<'a, R, G, T> !Send for ReentrantMutexGuard<'a, R, G, T>

impl<'a, R, G, T> !Send for MappedReentrantMutexGuard<'a, R, G, T>

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

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

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

impl Send for GuardSend

impl !Send for GuardNoSend

impl Send for Error

impl<'k> Send for Key<'k>

impl<S> Send for AsMap<S> where
    S: Send

impl<S> Send for AsList<S> where
    S: Send

impl<'v> !Send for Value<'v>

impl Send for Level

impl Send for LevelFilter

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

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

impl<'a> Send for Metadata<'a>

impl<'a> Send for MetadataBuilder<'a>

impl<S, A> Send for Pattern<S, A> where
    A: Send

impl<'a, S, A> Send for Matcher<'a, S, A> where
    A: Send,
    S: Send

impl<'a> Send for Memchr<'a>

impl<'a> Send for Memchr2<'a>

impl<'a> Send for Memchr3<'a>

impl Send for Prefilter

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

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

impl<'n> Send for Finder<'n>

impl<'n> Send for FinderRev<'n>

impl Send for MmapOptions

impl Send for Mmap

impl Send for MmapRaw

impl Send for MmapMut

impl<T> Send for MemCounter<T> where
    T: Send

impl<T> Send for NoopTracker<T> where
    T: Send

impl<H, KF, T, M> Send for MemoryDB<H, KF, T, M> where
    KF: Send,
    M: Send,
    T: Send

impl<H> Send for HashKey<H> where
    H: Send

impl<H> Send for PrefixedKey<H> where
    H: Send

impl<H> Send for LegacyPrefixedKey<H>

impl Send for Words

impl Send for Pages

impl Send for Words

impl Send for Pages

impl Send for Bytes

impl Send for Transcript

impl Send for ByteSlice

impl Send for ByteVec

impl Send for Type

impl Send for Tag

impl<'b> Send for Decoder<'b>

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

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

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

impl<'a, 'b, K, V> Send for MapIter<'a, 'b, K, V> where
    K: Sync,
    V: Sync

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

impl Send for Error

impl<W> Send for Encoder<W> where
    W: Send

impl<W> Send for Error<W> where
    W: Send

impl Send for EndOfSlice

impl Send for TDEFLFlush

impl Send for TDEFLStatus

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

impl Send for MinReset

impl Send for ZeroReset

impl Send for FullReset

impl Send for TINFLStatus

impl Send for MZFlush

impl Send for MZStatus

impl Send for MZError

impl Send for DataFormat

impl Send for PollOpt

impl Send for Ready

impl Send for Event

impl Send for Poll

impl Send for Events

impl<'a> Send for Iter<'a>

impl<'a> Send for EventedFd<'a>

impl Send for UnixReady

impl Send for Token

impl Send for TcpStream

impl Send for TcpListener

impl Send for UdpSocket

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

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

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

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

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

impl<T> Send for Timer<T> where
    T: Send

impl Send for Builder

impl Send for Timeout

impl Send for UnixStream

impl Send for Base

impl Send for Error

impl Send for Error

impl<const S: usize> Send for IdentityHasher<S>

impl<const S: usize> Send for Multihash<S>

impl<R, N> Send for ListenerSelectFuture<R, N> where
    N: Send,
    R: Send

impl<TInner> Send for Negotiated<TInner> where
    TInner: Send

impl<TInner> Send for NegotiatedComplete<TInner> where
    TInner: Send

impl Send for Version

impl<T> Send for X<T> where
    T: Send

impl<T> Send for XY<T> where
    T: Send

impl<T> Send for XYZ<T> where
    T: Send

impl<T> Send for XYZW<T> where
    T: Send

impl<T> Send for XYZWA<T> where
    T: Send

impl<T> Send for XYZWAB<T> where
    T: Send

impl<T> Send for IJKW<T> where
    T: Send

impl<T> Send for M2x2<T> where
    T: Send

impl<T> Send for M2x3<T> where
    T: Send

impl<T> Send for M2x4<T> where
    T: Send

impl<T> Send for M2x5<T> where
    T: Send

impl<T> Send for M2x6<T> where
    T: Send

impl<T> Send for M3x2<T> where
    T: Send

impl<T> Send for M3x3<T> where
    T: Send

impl<T> Send for M3x4<T> where
    T: Send

impl<T> Send for M3x5<T> where
    T: Send

impl<T> Send for M3x6<T> where
    T: Send

impl<T> Send for M4x2<T> where
    T: Send

impl<T> Send for M4x3<T> where
    T: Send

impl<T> Send for M4x4<T> where
    T: Send

impl<T> Send for M4x5<T> where
    T: Send

impl<T> Send for M4x6<T> where
    T: Send

impl<T> Send for M5x2<T> where
    T: Send

impl<T> Send for M5x3<T> where
    T: Send

impl<T> Send for M5x4<T> where
    T: Send

impl<T> Send for M5x5<T> where
    T: Send

impl<T> Send for M5x6<T> where
    T: Send

impl<T> Send for M6x2<T> where
    T: Send

impl<T> Send for M6x3<T> where
    T: Send

impl<T> Send for M6x4<T> where
    T: Send

impl<T> Send for M6x5<T> where
    T: Send

impl<T> Send for M6x6<T> where
    T: Send

impl Send for Dynamic

impl<const R: usize> Send for Const<R>

impl<'a, T, R, C, S> !Send for MatrixIter<'a, T, R, C, S>

impl<'a, T, R, C, S> !Send for MatrixIterMut<'a, T, R, C, S>

impl<'a, T, R, C, S> Send for RowIter<'a, T, R, C, S> where
    S: Sync,
    T: Sync

impl<'a, T, R, C, S> !Send for RowIterMut<'a, T, R, C, S>

impl<'a, T, R, C, S> Send for ColumnIter<'a, T, R, C, S> where
    S: Sync,
    T: Sync

impl<'a, T, R, C, S> !Send for ColumnIterMut<'a, T, R, C, S>

impl<T, const R: usize, const C: usize> Send for ArrayStorage<T, R, C> where
    T: Send

impl<T, R, C, S> Send for Matrix<T, R, C, S> where
    C: Send,
    R: Send,
    S: Send,
    T: Send

impl Send for LpNorm

impl Send for UniformNorm

impl<T> Send for Unit<T> where
    T: Send

impl<T, R, C> Send for VecStorage<T, R, C> where
    T: Send

impl<T, const D: usize> Send for Point<T, D> where
    T: Send

impl<T, const D: usize> Send for Rotation<T, D> where
    T: Send

impl<T> Send for Quaternion<T> where
    T: Send

impl<T> Send for DualQuaternion<T> where
    T: Send

impl<T, const D: usize> Send for Translation<T, D> where
    T: Send

impl<T, R, const D: usize> Send for Isometry<T, R, D> where
    R: Send,
    T: Send

impl<T, R, const D: usize> Send for Similarity<T, R, D> where
    R: Send,
    T: Send

impl Send for TGeneral

impl Send for TProjective

impl Send for TAffine

impl<T, C, const D: usize> !Send for Transform<T, C, D>

impl<T, D, S> Send for Reflection<T, D, S> where
    S: Send,
    T: Send

impl<T> Send for Orthographic3<T>

impl<T> Send for Perspective3<T> where
    T: Send

impl<T, R, C> !Send for Bidiagonal<T, R, C>

impl<T, D> !Send for Cholesky<T, D>

impl<T, R, C> !Send for ColPivQR<T, R, C>

impl<T, R, C> !Send for FullPivLU<T, R, C>

impl<T> Send for GivensRotation<T>

impl<T, D> !Send for Hessenberg<T, D>

impl<T, R, C> !Send for LU<T, R, C>

impl<D> !Send for PermutationSequence<D>

impl<T, R, C> !Send for QR<T, R, C>

impl<T, D> !Send for Schur<T, D>

impl<T, R, C> !Send for SVD<T, R, C>

impl<T, D> !Send for SymmetricEigen<T, D>

impl<T, D> !Send for SymmetricTridiagonal<T, D>

impl<T, D> !Send for UDU<T, D>

impl Send for Name

impl<'a> Send for Generator<'a>

impl Send for TcpBuilder

impl Send for UdpBuilder

impl<T> Send for NoHashHasher<T> where
    T: Send

impl Send for Sign

impl Send for BigInt

impl Send for BigUint

impl<T> Send for Complex<T> where
    T: Send

impl<E> Send for ParseComplexError<E> where
    E: Send

impl<A> Send for ExtendedGcd<A> where
    A: Send

impl<T> Send for IterBinomial<T> where
    T: Send

impl<T> Send for Ratio<T> where
    T: Send

impl Send for AddressSize

impl Send for SectionKind

impl Send for ComdatKind

impl Send for SymbolKind

impl Send for SymbolScope

impl Send for FileFlags

impl<Section> Send for SymbolFlags<Section> where
    Section: Send

impl Send for Endianness

impl Send for BigEndian

impl<E> Send for U16Bytes<E> where
    E: Send

impl<E> Send for U32Bytes<E> where
    E: Send

impl<E> Send for U64Bytes<E> where
    E: Send

impl<E> Send for I16Bytes<E> where
    E: Send

impl<E> Send for I32Bytes<E> where
    E: Send

impl<E> Send for I64Bytes<E> where
    E: Send

impl<'data> Send for Bytes<'data>

impl<'data, R> Send for StringTable<'data, R> where
    R: Send

impl<'data, R> Send for File<'data, R> where
    R: Send

impl<'data, 'file, R> Send for SegmentIterator<'data, 'file, R> where
    R: Sync

impl<'data, 'file, R> Send for Segment<'data, 'file, R> where
    R: Sync

impl<'data, 'file, R> Send for SectionIterator<'data, 'file, R> where
    R: Sync

impl<'data, 'file, R> Send for Section<'data, 'file, R> where
    R: Sync

impl<'data, 'file, R> Send for ComdatIterator<'data, 'file, R> where
    R: Sync

impl<'data, 'file, R> Send for Comdat<'data, 'file, R> where
    R: Sync

impl<'data, 'file, R> Send for ComdatSectionIterator<'data, 'file, R> where
    R: Sync

impl<'data, 'file, R> Send for SymbolTable<'data, 'file, R> where
    R: Send + Sync

impl<'data, 'file, R> Send for SymbolIterator<'data, 'file, R> where
    R: Send + Sync

impl<'data, 'file, R> Send for Symbol<'data, 'file, R> where
    R: Send + Sync

impl<'data, 'file, R> Send for DynamicRelocationIterator<'data, 'file, R> where
    R: Send + Sync

impl<'data, 'file, R> Send for SectionRelocationIterator<'data, 'file, R> where
    R: Send + Sync

impl Send for ArchiveKind

impl<'data, R> Send for ArchiveFile<'data, R> where
    R: Send

impl<'data, R> Send for ArchiveMemberIterator<'data, R> where
    R: Send

impl<'data> Send for ArchiveMember<'data>

impl<'data, R> Send for CoffFile<'data, R> where
    R: Send

impl<'data> Send for SectionTable<'data>

impl<'data, 'file, R> Send for CoffSegmentIterator<'data, 'file, R> where
    R: Sync

impl<'data, 'file, R> Send for CoffSegment<'data, 'file, R> where
    R: Sync

impl<'data, 'file, R> Send for CoffSectionIterator<'data, 'file, R> where
    R: Sync

impl<'data, 'file, R> Send for CoffSection<'data, 'file, R> where
    R: Sync

impl<'data, R> Send for SymbolTable<'data, R> where
    R: Send

impl<'data, 'table, R> Send for SymbolIterator<'data, 'table, R> where
    R: Sync

impl<'data, 'file, R> Send for CoffSymbolTable<'data, 'file, R> where
    R: Sync

impl<'data, 'file, R> Send for CoffSymbolIterator<'data, 'file, R> where
    R: Sync

impl<'data, 'file, R> Send for CoffSymbol<'data, 'file, R> where
    R: Sync

impl<'data, 'file, R> Send for CoffRelocationIterator<'data, 'file, R> where
    R: Sync

impl<'data, 'file, R> Send for CoffComdatIterator<'data, 'file, R> where
    R: Sync

impl<'data, 'file, R> Send for CoffComdat<'data, 'file, R> where
    R: Sync

impl<'data, 'file, R> Send for CoffComdatSectionIterator<'data, 'file, R> where
    R: Sync

impl<'data, Elf, R> Send for ElfFile<'data, Elf, R> where
    Elf: Sync,
    R: Send,
    <Elf as FileHeader>::Endian: Send,
    <Elf as FileHeader>::ProgramHeader: Sync,
    <Elf as FileHeader>::SectionHeader: Sync,
    <Elf as FileHeader>::Sym: Sync

impl<'data, 'file, Elf, R> Send for ElfSegmentIterator<'data, 'file, Elf, R> where
    Elf: Sync,
    R: Sync,
    <Elf as FileHeader>::Endian: Sync,
    <Elf as FileHeader>::ProgramHeader: Sync,
    <Elf as FileHeader>::SectionHeader: Sync,
    <Elf as FileHeader>::Sym: Sync

impl<'data, 'file, Elf, R> Send for ElfSegment<'data, 'file, Elf, R> where
    Elf: Sync,
    R: Sync,
    <Elf as FileHeader>::Endian: Sync,
    <Elf as FileHeader>::ProgramHeader: Sync,
    <Elf as FileHeader>::SectionHeader: Sync,
    <Elf as FileHeader>::Sym: Sync

impl<'data, Elf, R> Send for SectionTable<'data, Elf, R> where
    R: Send,
    <Elf as FileHeader>::SectionHeader: Sync

impl<'data, 'file, Elf, R> Send for ElfSectionIterator<'data, 'file, Elf, R> where
    Elf: Sync,
    R: Sync,
    <Elf as FileHeader>::Endian: Sync,
    <Elf as FileHeader>::ProgramHeader: Sync,
    <Elf as FileHeader>::SectionHeader: Sync,
    <Elf as FileHeader>::Sym: Sync

impl<'data, 'file, Elf, R> Send for ElfSection<'data, 'file, Elf, R> where
    Elf: Sync,
    R: Sync,
    <Elf as FileHeader>::Endian: Sync,
    <Elf as FileHeader>::ProgramHeader: Sync,
    <Elf as FileHeader>::SectionHeader: Sync,
    <Elf as FileHeader>::Sym: Sync

impl<'data, Elf, R> Send for SymbolTable<'data, Elf, R> where
    R: Send,
    <Elf as FileHeader>::Sym: Sync

impl<'data, 'file, Elf, R> Send for ElfSymbolTable<'data, 'file, Elf, R> where
    R: Sync,
    <Elf as FileHeader>::Endian: Send,
    <Elf as FileHeader>::Sym: Sync

impl<'data, 'file, Elf, R> Send for ElfSymbolIterator<'data, 'file, Elf, R> where
    R: Sync,
    <Elf as FileHeader>::Endian: Send,
    <Elf as FileHeader>::Sym: Sync

impl<'data, 'file, Elf, R> Send for ElfSymbol<'data, 'file, Elf, R> where
    R: Sync,
    <Elf as FileHeader>::Endian: Send,
    <Elf as FileHeader>::Sym: Sync

impl<'data, 'file, Elf, R> Send for ElfDynamicRelocationIterator<'data, 'file, Elf, R> where
    Elf: Sync,
    R: Sync,
    <Elf as FileHeader>::Endian: Sync,
    <Elf as FileHeader>::ProgramHeader: Sync,
    <Elf as FileHeader>::Rel: Sync,
    <Elf as FileHeader>::Rela: Sync,
    <Elf as FileHeader>::SectionHeader: Sync,
    <Elf as FileHeader>::Sym: Sync

impl<'data, 'file, Elf, R> Send for ElfSectionRelocationIterator<'data, 'file, Elf, R> where
    Elf: Sync,
    R: Sync,
    <Elf as FileHeader>::Endian: Sync,
    <Elf as FileHeader>::ProgramHeader: Sync,
    <Elf as FileHeader>::Rel: Sync,
    <Elf as FileHeader>::Rela: Sync,
    <Elf as FileHeader>::SectionHeader: Sync,
    <Elf as FileHeader>::Sym: Sync

impl<'data, 'file, Elf, R> Send for ElfComdatIterator<'data, 'file, Elf, R> where
    Elf: Sync,
    R: Sync,
    <Elf as FileHeader>::Endian: Sync,
    <Elf as FileHeader>::ProgramHeader: Sync,
    <Elf as FileHeader>::SectionHeader: Sync,
    <Elf as FileHeader>::Sym: Sync

impl<'data, 'file, Elf, R> Send for ElfComdat<'data, 'file, Elf, R> where
    Elf: Sync,
    R: Sync,
    <Elf as FileHeader>::Endian: Sync,
    <Elf as FileHeader>::ProgramHeader: Sync,
    <Elf as FileHeader>::SectionHeader: Sync,
    <Elf as FileHeader>::Sym: Sync

impl<'data, 'file, Elf, R> Send for ElfComdatSectionIterator<'data, 'file, Elf, R> where
    Elf: Sync,
    R: Sync,
    <Elf as FileHeader>::Endian: Sync,
    <Elf as FileHeader>::ProgramHeader: Sync,
    <Elf as FileHeader>::SectionHeader: Sync,
    <Elf as FileHeader>::Sym: Sync

impl<'data, Elf> Send for NoteIterator<'data, Elf> where
    <Elf as FileHeader>::Endian: Send

impl<'data, Elf> Send for Note<'data, Elf> where
    <Elf as FileHeader>::NoteHeader: Sync

impl<'data, Elf> Send for HashTable<'data, Elf> where
    <Elf as FileHeader>::Endian: Sync

impl<'data, Elf> Send for GnuHashTable<'data, Elf> where
    <Elf as FileHeader>::Endian: Sync

impl<'data, Elf> Send for VerdefIterator<'data, Elf> where
    <Elf as FileHeader>::Endian: Send

impl<'data, Elf> Send for VerdauxIterator<'data, Elf> where
    <Elf as FileHeader>::Endian: Send

impl<'data, Elf> Send for VerneedIterator<'data, Elf> where
    <Elf as FileHeader>::Endian: Send

impl<'data, Elf> Send for VernauxIterator<'data, Elf> where
    <Elf as FileHeader>::Endian: Send

impl<'data, E, R> Send for DyldCache<'data, E, R> where
    E: Send + Sync,
    R: Send

impl<'data, 'cache, E, R> Send for DyldCacheImageIterator<'data, 'cache, E, R> where
    E: Sync,
    R: Sync

impl<'data, E, R> Send for DyldCacheImage<'data, E, R> where
    E: Send + Sync,
    R: Send

impl<'data, Mach, R> Send for MachOFile<'data, Mach, R> where
    Mach: Sync,
    R: Send,
    <Mach as MachHeader>::Endian: Send,
    <Mach as MachHeader>::Nlist: Sync,
    <Mach as MachHeader>::Section: Sync

impl<'data, 'file, Mach, R> Send for MachOComdatIterator<'data, 'file, Mach, R> where
    Mach: Sync,
    R: Sync,
    <Mach as MachHeader>::Endian: Sync,
    <Mach as MachHeader>::Nlist: Sync,
    <Mach as MachHeader>::Section: Sync

impl<'data, 'file, Mach, R> Send for MachOComdat<'data, 'file, Mach, R> where
    Mach: Sync,
    R: Sync,
    <Mach as MachHeader>::Endian: Sync,
    <Mach as MachHeader>::Nlist: Sync,
    <Mach as MachHeader>::Section: Sync

impl<'data, 'file, Mach, R> Send for MachOComdatSectionIterator<'data, 'file, Mach, R> where
    Mach: Sync,
    R: Sync,
    <Mach as MachHeader>::Endian: Sync,
    <Mach as MachHeader>::Nlist: Sync,
    <Mach as MachHeader>::Section: Sync

impl<'data, E> Send for LoadCommandIterator<'data, E> where
    E: Send

impl<'data, E> Send for LoadCommandData<'data, E> where
    E: Send

impl<'data, E> Send for LoadCommandVariant<'data, E> where
    E: Sync

impl<'data, 'file, Mach, R> Send for MachOSegmentIterator<'data, 'file, Mach, R> where
    Mach: Sync,
    R: Sync,
    <Mach as MachHeader>::Endian: Send + Sync,
    <Mach as MachHeader>::Nlist: Sync,
    <Mach as MachHeader>::Section: Sync

impl<'data, 'file, Mach, R> Send for MachOSegment<'data, 'file, Mach, R> where
    Mach: Sync,
    R: Sync,
    <Mach as MachHeader>::Endian: Sync,
    <Mach as MachHeader>::Nlist: Sync,
    <Mach as MachHeader>::Section: Sync,
    <Mach as MachHeader>::Segment: Sync

impl<'data, 'file, Mach, R> Send for MachOSectionIterator<'data, 'file, Mach, R> where
    Mach: Sync,
    R: Sync,
    <Mach as MachHeader>::Endian: Sync,
    <Mach as MachHeader>::Nlist: Sync,
    <Mach as MachHeader>::Section: Sync

impl<'data, 'file, Mach, R> Send for MachOSection<'data, 'file, Mach, R> where
    Mach: Sync,
    R: Sync,
    <Mach as MachHeader>::Endian: Sync,
    <Mach as MachHeader>::Nlist: Sync,
    <Mach as MachHeader>::Section: Sync

impl<'data, Mach, R> Send for SymbolTable<'data, Mach, R> where
    R: Send,
    <Mach as MachHeader>::Nlist: Sync

impl<'data, 'file, Mach, R> Send for MachOSymbolTable<'data, 'file, Mach, R> where
    Mach: Sync,
    R: Sync,
    <Mach as MachHeader>::Endian: Sync,
    <Mach as MachHeader>::Nlist: Sync,
    <Mach as MachHeader>::Section: Sync

impl<'data, 'file, Mach, R> Send for MachOSymbolIterator<'data, 'file, Mach, R> where
    Mach: Sync,
    R: Sync,
    <Mach as MachHeader>::Endian: Sync,
    <Mach as MachHeader>::Nlist: Sync,
    <Mach as MachHeader>::Section: Sync

impl<'data, 'file, Mach, R> Send for MachOSymbol<'data, 'file, Mach, R> where
    Mach: Sync,
    R: Sync,
    <Mach as MachHeader>::Endian: Sync,
    <Mach as MachHeader>::Nlist: Sync,
    <Mach as MachHeader>::Section: Sync

impl<'data, 'file, Mach, R> Send for MachORelocationIterator<'data, 'file, Mach, R> where
    Mach: Sync,
    R: Sync,
    <Mach as MachHeader>::Endian: Sync,
    <Mach as MachHeader>::Nlist: Sync,
    <Mach as MachHeader>::Section: Sync

impl<'data, Pe, R> Send for PeFile<'data, Pe, R> where
    Pe: Sync,
    R: Send

impl<'data, 'file, Pe, R> Send for PeComdatIterator<'data, 'file, Pe, R> where
    Pe: Sync,
    R: Sync

impl<'data, 'file, Pe, R> Send for PeComdat<'data, 'file, Pe, R> where
    Pe: Sync,
    R: Sync

impl<'data, 'file, Pe, R> Send for PeComdatSectionIterator<'data, 'file, Pe, R> where
    Pe: Sync,
    R: Sync

impl<'data, 'file, Pe, R> Send for PeSegmentIterator<'data, 'file, Pe, R> where
    Pe: Sync,
    R: Sync

impl<'data, 'file, Pe, R> Send for PeSegment<'data, 'file, Pe, R> where
    Pe: Sync,
    R: Sync

impl<'data, 'file, Pe, R> Send for PeSectionIterator<'data, 'file, Pe, R> where
    Pe: Sync,
    R: Sync

impl<'data, 'file, Pe, R> Send for PeSection<'data, 'file, Pe, R> where
    Pe: Sync,
    R: Sync

impl<'data, 'file, R> Send for PeRelocationIterator<'data, 'file, R> where
    R: Send

impl Send for Error

impl Send for FileKind

impl Send for SymbolIndex

impl<T> Send for SymbolMap<T> where
    T: Send

impl<'data> Send for SymbolMapName<'data>

impl<'data> Send for ObjectMap<'data>

impl<'data> Send for ObjectMapEntry<'data>

impl<'data> Send for Import<'data>

impl<'data> Send for Export<'data>

impl<'data> Send for CodeView<'data>

impl Send for Relocation

impl<'data> Send for CompressedData<'data>

impl Send for Header

impl<E> Send for FileHeader32<E> where
    E: Send

impl<E> Send for FileHeader64<E> where
    E: Send

impl Send for Ident

impl<E> Send for SectionHeader32<E> where
    E: Send

impl<E> Send for SectionHeader64<E> where
    E: Send

impl<E> Send for CompressionHeader32<E> where
    E: Send

impl<E> Send for CompressionHeader64<E> where
    E: Send

impl<E> Send for Sym32<E> where
    E: Send

impl<E> Send for Sym64<E> where
    E: Send

impl<E> Send for Syminfo32<E> where
    E: Send

impl<E> Send for Syminfo64<E> where
    E: Send

impl<E> Send for Rel32<E> where
    E: Send

impl<E> Send for Rela32<E> where
    E: Send

impl<E> Send for Rel64<E> where
    E: Send

impl<E> Send for Rela64<E> where
    E: Send

impl<E> Send for ProgramHeader32<E> where
    E: Send

impl<E> Send for ProgramHeader64<E> where
    E: Send

impl<E> Send for Dyn32<E> where
    E: Send

impl<E> Send for Dyn64<E> where
    E: Send

impl<E> Send for Versym<E> where
    E: Send

impl<E> Send for Verdef<E> where
    E: Send

impl<E> Send for Verdaux<E> where
    E: Send

impl<E> Send for Verneed<E> where
    E: Send

impl<E> Send for Vernaux<E> where
    E: Send

impl<E> Send for NoteHeader32<E> where
    E: Send

impl<E> Send for NoteHeader64<E> where
    E: Send

impl<E> Send for HashHeader<E> where
    E: Send

impl<E> Send for GnuHashHeader<E> where
    E: Send

impl<E> Send for DyldCacheHeader<E> where
    E: Send

impl<E> Send for DyldCacheMappingInfo<E> where
    E: Send

impl<E> Send for DyldCacheImageInfo<E> where
    E: Send

impl Send for FatHeader

impl Send for FatArch32

impl Send for FatArch64

impl<E> Send for MachHeader32<E> where
    E: Send

impl<E> Send for MachHeader64<E> where
    E: Send

impl<E> Send for LoadCommand<E> where
    E: Send

impl<E> Send for LcStr<E> where
    E: Send

impl<E> Send for SegmentCommand32<E> where
    E: Send

impl<E> Send for SegmentCommand64<E> where
    E: Send

impl<E> Send for Section32<E> where
    E: Send

impl<E> Send for Section64<E> where
    E: Send

impl<E> Send for Fvmlib<E> where
    E: Send

impl<E> Send for FvmlibCommand<E> where
    E: Send

impl<E> Send for Dylib<E> where
    E: Send

impl<E> Send for DylibCommand<E> where
    E: Send

impl<E> Send for SubFrameworkCommand<E> where
    E: Send

impl<E> Send for SubClientCommand<E> where
    E: Send

impl<E> Send for SubUmbrellaCommand<E> where
    E: Send

impl<E> Send for SubLibraryCommand<E> where
    E: Send

impl<E> Send for PreboundDylibCommand<E> where
    E: Send

impl<E> Send for DylinkerCommand<E> where
    E: Send

impl<E> Send for ThreadCommand<E> where
    E: Send

impl<E> Send for RoutinesCommand32<E> where
    E: Send

impl<E> Send for RoutinesCommand64<E> where
    E: Send

impl<E> Send for SymtabCommand<E> where
    E: Send

impl<E> Send for DysymtabCommand<E> where
    E: Send

impl<E> Send for DylibTableOfContents<E> where
    E: Send

impl<E> Send for DylibModule32<E> where
    E: Send

impl<E> Send for DylibModule64<E> where
    E: Send

impl<E> Send for DylibReference<E> where
    E: Send

impl<E> Send for TwolevelHintsCommand<E> where
    E: Send

impl<E> Send for TwolevelHint<E> where
    E: Send

impl<E> Send for PrebindCksumCommand<E> where
    E: Send

impl<E> Send for UuidCommand<E> where
    E: Send

impl<E> Send for RpathCommand<E> where
    E: Send

impl<E> Send for LinkeditDataCommand<E> where
    E: Send

impl<E> Send for FilesetEntryCommand<E> where
    E: Send

impl<E> Send for EncryptionInfoCommand32<E> where
    E: Send

impl<E> Send for EncryptionInfoCommand64<E> where
    E: Send

impl<E> Send for VersionMinCommand<E> where
    E: Send

impl<E> Send for BuildVersionCommand<E> where
    E: Send

impl<E> Send for BuildToolVersion<E> where
    E: Send

impl<E> Send for DyldInfoCommand<E> where
    E: Send

impl<E> Send for LinkerOptionCommand<E> where
    E: Send

impl<E> Send for SymsegCommand<E> where
    E: Send

impl<E> Send for IdentCommand<E> where
    E: Send

impl<E> Send for FvmfileCommand<E> where
    E: Send

impl<E> Send for EntryPointCommand<E> where
    E: Send

impl<E> Send for SourceVersionCommand<E> where
    E: Send

impl<E> Send for DataInCodeEntry<E> where
    E: Send

impl<E> Send for NoteCommand<E> where
    E: Send

impl<E> Send for Nlist32<E> where
    E: Send

impl<E> Send for Nlist64<E> where
    E: Send

impl<E> Send for Relocation<E> where
    E: Send

impl Send for Guid

impl Send for ImageSymbol

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

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

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

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

impl<T> Send for OnceBox<T> where
    T: Send

impl Send for OnceBool

impl Send for ProbeResult

impl<T> Send for AnagolayWeight<T> where
    T: Send

impl<T> Send for Pallet<T> where
    T: Send

impl<T> Send for GenesisConfig<T>

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

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

impl<T> Send for Call<T> where
    T: Send

impl<T> Send for _GeneratedPrefixForStorageVersionByVersionId<T> where
    T: Send

impl<T> Send for _GeneratedPrefixForStorageTotal<T> where
    T: Send

impl<O, H> Send for OwningHandle<O, H> where
    H: Send,
    O: Send

impl<T> Send for Pallet<T> where
    T: Send

impl<T> Send for GenesisConfig<T>

impl<T> Send for Call<T> where
    T: Send

impl<T> Send for SealVerify<T> where
    T: Send

impl<T, N> Send for OnePerAuthorPerHeight<T, N> where
    N: Send,
    T: Send

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

impl<T> Send for Module<T> where
    T: Send

impl<T> Send for Call<T> where
    T: Send

impl<T> Send for SubstrateWeight<T> where
    T: Send

impl<T, I> Send for Pallet<T, I> where
    I: Send,
    T: Send

impl<T, I> Send for Event<T, I> where
    I: Send,
    T: Send

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

impl<T, I> Send for GenesisConfig<T, I>

impl<T, I> Send for Call<T, I> where
    I: Send,
    T: Send,
    <<T as Config>::Lookup as StaticLookup>::Source: Send

impl<T, I> Send for _GeneratedPrefixForStorageTotalIssuance<T, I> where
    I: Send,
    T: Send

impl<T, I> Send for _GeneratedPrefixForStorageAccount<T, I> where
    I: Send,
    T: Send

impl<T, I> Send for _GeneratedPrefixForStorageLocks<T, I> where
    I: Send,
    T: Send

impl<T, I> Send for PositiveImbalance<T, I>

impl<T, I> Send for NegativeImbalance<T, I>

impl Send for Reasons

impl<Balance> Send for BalanceLock<Balance> where
    Balance: Send

impl<Balance> Send for AccountData<Balance> where
    Balance: Send

impl<I, R, L, O> Send for EquivocationHandler<I, R, L, O> where
    I: Send,
    L: Send,
    O: Send,
    R: Send

impl<FullIdentification> Send for GrandpaEquivocationOffence<FullIdentification> where
    FullIdentification: Send

impl<N> Send for OldStoredPendingChange<N> where
    N: Send

impl<N> Send for StoredPendingChange<N> where
    N: Send

impl<N> Send for StoredState<N> where
    N: Send

impl Send for Event

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

impl<T> Send for Module<T> where
    T: Send

impl<T> Send for Call<T> where
    T: Send,
    <T as Config>::KeyOwnerProof: Send

impl<T> Send for Module<T> where
    T: Send

impl<T> Send for Call<T> where
    T: Send

impl<T> Send for SubstrateWeight<T> where
    T: Send

impl<Period, Offset> Send for PeriodicSessions<Period, Offset> where
    Offset: Send,
    Period: Send

impl<T> Send for GenesisConfig<T>

impl Send for Event

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

impl<T> Send for Module<T> where
    T: Send

impl<T> Send for Call<T> where
    T: Send

impl<T, Inner> Send for FindAccountFromAuthorIndex<T, Inner> where
    Inner: Send,
    T: Send

impl<T> Send for Module<T> where
    T: Send

impl<T> Send for Call<T> where
    T: Send,
    <T as Config>::Call: Send,
    <<T as Config>::Lookup as StaticLookup>::Source: Send

impl<AccountId> Send for RawEvent<AccountId> where
    AccountId: Send

impl<T> Send for GenesisConfig<T>

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

impl<T> Send for SubstrateWeight<T> where
    T: Send

impl<T> Send for Pallet<T> where
    T: Send

impl<T> Send for Call<T> where
    T: Send,
    <T as Config>::Moment: Send

impl<T> Send for _GeneratedPrefixForStorageNow<T> where
    T: Send

impl<C, OU> Send for CurrencyAdapter<C, OU> where
    C: Send,
    OU: Send

impl<Balance> Send for InclusionFee<Balance> where
    Balance: Send

impl<Balance> Send for FeeDetails<Balance> where
    Balance: Send

impl<Balance> Send for RuntimeDispatchInfo<Balance> where
    Balance: Send

impl<T, S, V, M> Send for TargetedFeeAdjustment<T, S, V, M> where
    M: Send,
    S: Send,
    T: Send,
    V: Send

impl<T> Send for Module<T> where
    T: Send

impl<T> Send for Call<T> where
    T: Send

impl<BlockHash, ResponseType> Send for Client<BlockHash, ResponseType> where
    BlockHash: Send,
    ResponseType: Send

impl<C, P> Send for TransactionPayment<C, P> where
    C: Send + Sync,
    P: Send

impl Send for Error

impl<T> Send for SubstrateWeight<T> where
    T: Send

impl Send for Event

impl<T> Send for Module<T> where
    T: Send

impl<T> Send for Call<T> where
    T: Send,
    <T as Config>::Call: Send

impl Send for Db

impl Send for Error

impl Send for Options

impl<'a> Send for Protocol<'a>

impl<'a> Send for Onion3Addr<'a>

impl Send for Error

impl Send for FromUrlErr

impl Send for Multiaddr

impl<'a> Send for Iter<'a>

impl<R> Send for IoReader<R> where
    R: Send

impl Send for OptionBool

impl<T> Send for Compact<T> where
    T: Send

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

impl Send for Error

impl Send for Endpoint

impl Send for RemoteId

impl Send for Incoming

impl Send for VarUint32

impl Send for VarUint64

impl Send for VarUint7

impl Send for VarInt7

impl Send for Uint8

impl Send for VarInt32

impl Send for VarInt64

impl Send for Uint32

impl Send for Uint64

impl Send for VarUint1

impl<T> Send for CountedList<T> where
    T: Send

impl<'a, W> Send for CountedWriter<'a, W> where
    W: Send

impl<I, T> Send for CountedListWriter<I, T> where
    T: Send

impl Send for Module

impl Send for Section

impl Send for TypeSection

impl Send for CodeSection

impl Send for DataSection

impl Send for Type

impl Send for ValueType

impl Send for BlockType

impl Send for GlobalType

impl Send for TableType

impl Send for MemoryType

impl Send for External

impl Send for ImportEntry

impl Send for Internal

impl Send for ExportEntry

impl Send for GlobalEntry

impl Send for InitExpr

impl Send for Instruction

impl Send for BrTableData

impl Send for Func

impl Send for Local

impl Send for FuncBody

impl Send for DataSegment

impl<T> Send for IndexMap<T> where
    T: Send

impl Send for NameSection

impl Send for Error

impl Send for Unparsed

impl Send for Identity

impl<F> Send for ModuleBuilder<F> where
    F: Send

impl<F> Send for SignatureBuilder<F> where
    F: Send

impl<F> Send for TypeRefBuilder<F> where
    F: Send

impl<F> Send for SignaturesBuilder<F> where
    F: Send

impl<F> Send for FuncBodyBuilder<F> where
    F: Send

impl<F> Send for FunctionBuilder<F> where
    F: Send

impl<F> Send for ImportBuilder<F> where
    F: Send

impl<F> Send for MemoryBuilder<F> where
    F: Send

impl<F> Send for TableBuilder<F> where
    F: Send

impl<F> Send for ExportBuilder<F> where
    F: Send

impl<F> Send for ExportInternalBuilder<F> where
    F: Send

impl<F> Send for GlobalBuilder<F> where
    F: Send

impl<F> Send for DataSegmentBuilder<F> where
    F: Send

impl Send for Sender

impl Send for Frame

impl Send for Handshake

impl Send for Request

impl Send for Response

impl Send for Message

impl Send for OpCode

impl Send for CloseCode

impl Send for Kind

impl Send for Error

impl Send for Settings

impl<F> Send for WebSocket<F> where
    F: Send,
    <F as Factory>::Handler: Send

impl Send for Builder

impl Send for Parker

impl Send for Unparker

impl Send for Condvar

impl Send for OnceState

impl Send for Once

impl Send for RawMutex

impl Send for RawRwLock

impl Send for RawThreadId

impl Send for ParkResult

impl Send for RequeueOp

impl Send for FilterOp

impl Send for UnparkToken

impl Send for ParkToken

impl Send for SpinWait

impl Send for AsciiSet

impl<'a> Send for PercentEncode<'a>

impl<'a> Send for PercentDecode<'a>

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

impl<R> Send for ErrorVariant<R> where
    R: Send

impl<'i, R> !Send for FlatPairs<'i, R>

impl<'i, R> !Send for Pair<'i, R>

impl<'i, R> !Send for Pairs<'i, R>

impl<'i, R> !Send for Tokens<'i, R>

impl Send for Lookahead

impl Send for Atomicity

impl Send for MatchDir

impl<'i, R> Send for ParserState<'i, R> where
    R: Send

impl<'i> Send for Position<'i>

impl Send for Assoc

impl<R> Send for Operator<R> where
    R: Send

impl<R> Send for PrecClimber<R> where
    R: Send

impl<'i> Send for Span<'i>

impl<'i> Send for Lines<'i>

impl<'i, R> Send for Token<'i, R> where
    R: Send

impl Send for Rule

impl Send for RuleType

impl Send for Expr

impl Send for PestParser

impl Send for Rule

impl<'i> Send for ParserRule<'i>

impl<'i> Send for ParserNode<'i>

impl<'i> Send for ParserExpr<'i>

impl Send for Event

impl Send for Poller

impl Send for Poly1305

impl Send for Polyval

impl Send for YesS3

impl Send for NoS3

impl Send for YesS4

impl Send for NoS4

impl Send for YesA1

impl Send for NoA1

impl Send for YesA2

impl Send for NoA2

impl Send for YesNI

impl Send for NoNI

impl<S3, S4, NI> Send for SseMachine<S3, S4, NI> where
    NI: Send,
    S3: Send,
    S4: Send

impl<NI> Send for Avx2Machine<NI> where
    NI: Send

impl Send for Error

impl Send for U128

impl Send for U256

impl Send for U512

impl Send for H128

impl Send for H160

impl Send for H256

impl Send for H512

impl !Send for IntoIter

impl !Send for TokenStream

impl !Send for LexError

impl Send for LineColumn

impl !Send for Span

impl !Send for TokenTree

impl !Send for Group

impl Send for Delimiter

impl !Send for Punct

impl Send for Spacing

impl !Send for Ident

impl !Send for Literal

impl Send for Level

impl !Send for Diagnostic

impl !Send for SpanRange

impl Send for LabelPair

impl Send for Gauge

impl Send for Counter

impl Send for Quantile

impl Send for Summary

impl Send for Untyped

impl Send for Histogram

impl Send for Bucket

impl Send for Metric

impl Send for MetricType

impl Send for AtomicF64

impl Send for AtomicI64

impl Send for AtomicU64

impl<T, V, D> Send for AFLocalCounter<T, V, D> where
    D: Send,
    T: Send,
    V: Send

impl<T, D> Send for AFLocalHistogram<T, D> where
    D: Send,
    T: Send

impl<P> Send for GenericCounter<P>

impl<P> Send for GenericLocalCounter<P>

impl Send for Desc

impl Send for TextEncoder

impl Send for Error

impl<P> Send for GenericGauge<P>

impl Send for Histogram

impl Send for Opts

impl Send for Registry

impl<T> Send for MetricVec<T>

impl Send for DecodeError

impl Send for EncodeError

impl Send for Metering

impl Send for Set

impl Send for Error

impl Send for Error

impl Send for Error

impl !Send for Module

impl<T> Send for Entry<T> where
    T: Send

impl<T> !Send for EntryRef<T>

impl<T> !Send for RefList<T>

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

impl Send for Error

impl<X, E> Send for Context<X, E> where
    E: Send,
    X: Send

impl<A> Send for Action<A> where
    A: Send

impl<S, F, T, A, E> Send for SinkImpl<S, F, T, A, E> where
    A: Send,
    E: Send,
    F: Send,
    S: Send,
    T: Send

impl Send for Bernoulli

impl<D, R, T> Send for DistIter<D, R, T> where
    D: Send,
    R: Send,
    T: Send

impl<D, F, T, S> Send for DistMap<D, F, T, S> where
    D: Send,
    F: Send

impl Send for Open01

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

impl<X> Send for WeightedIndex<X> where
    X: Send,
    <X as SampleUniform>::Sampler: Send

impl<X> Send for Uniform<X> where
    <X as SampleUniform>::Sampler: Send

impl<X> Send for UniformInt<X> where
    X: Send

impl Send for UniformChar

impl<X> Send for UniformFloat<X> where
    X: Send

impl<W> Send for WeightedIndex<W> where
    W: Send

impl Send for Standard

impl<R> Send for ReadRng<R> where
    R: Send

impl Send for ReadError

impl<R, Rsdr> Send for ReseedingRng<R, Rsdr> where
    R: Send,
    Rsdr: Send,
    <R as BlockRngCore>::Results: Send

impl Send for StepRng

impl Send for StdRng

impl !Send for ThreadRng

impl Send for IndexVec

impl<'a> Send for IndexVecIter<'a>

impl<'a, S: ?Sized, T> Send for SliceChooseIter<'a, S, T> where
    S: Sync,
    T: Send

impl Send for ChaCha20Rng

impl Send for ChaCha12Rng

impl Send for ChaCha8Core

impl Send for ChaCha8Rng

impl<R: ?Sized> Send for BlockRng<R> where
    R: Send,
    <R as BlockRngCore>::Results: Send

impl<R: ?Sized> Send for BlockRng64<R> where
    R: Send,
    <R as BlockRngCore>::Results: Send

impl Send for Error

impl Send for OsRng

impl Send for Binomial

impl Send for Error

impl<F> Send for Cauchy<F> where
    F: Send

impl Send for Error

impl Send for Exp1

impl<F> Send for Exp<F> where
    F: Send

impl Send for Error

impl<F> Send for Gamma<F> where
    F: Send

impl Send for Error

impl<F> Send for ChiSquared<F> where
    F: Send

impl<F> Send for FisherF<F> where
    F: Send

impl<F> Send for StudentT<F> where
    F: Send

impl<F> Send for Beta<F> where
    F: Send

impl Send for BetaError

impl Send for Geometric

impl Send for Error

impl Send for Error

impl Send for Error

impl<F> Send for InverseGaussian<F> where
    F: Send

impl<F> Send for Normal<F> where
    F: Send

impl Send for Error

impl<F> Send for LogNormal<F> where
    F: Send

impl Send for Error

impl<F> Send for NormalInverseGaussian<F> where
    F: Send

impl<F> Send for Pareto<F> where
    F: Send

impl Send for Error

impl<F> Send for Pert<F> where
    F: Send

impl Send for PertError

impl<F> Send for Poisson<F> where
    F: Send

impl Send for Error

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

impl Send for UnitBall

impl Send for UnitCircle

impl Send for UnitDisc

impl Send for UnitSphere

impl<F> Send for Weibull<F> where
    F: Send

impl Send for Error

impl Send for CpuId

impl Send for CpuIdResult

impl Send for VendorInfo

impl Send for CacheInfo

impl Send for FeatureInfo

impl Send for CacheType

impl Send for L3CatInfo

impl Send for L2CatInfo

impl Send for SgxInfo

impl Send for EpcSection

impl Send for TscInfo

impl Send for DatIter

impl Send for DatInfo

impl Send for DatType

impl Send for Hypervisor

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

impl<T> Send for IntoIter<T>

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

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

impl<K, V> Send for IntoIter<K, V>

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

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

impl<T> Send for IntoIter<T>

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

impl<K, V> Send for IntoIter<K, V>

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

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

impl<'a, K, V> Send for Drain<'a, K, V>

impl<T> Send for IntoIter<T>

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

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

impl<T> Send for IntoIter<T>

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

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

impl<T> Send for IntoIter<T>

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

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

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

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

impl<I> Send for Chunks<I>

impl<I> Send for Cloned<I>

impl<I> Send for Copied<I>

impl<T> Send for Empty<T>

impl<I> Send for Enumerate<I>

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

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

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

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

impl<I> Send for Flatten<I>

impl<I> Send for FlattenIter<I>

impl<I, ID, F> Send for Fold<I, ID, F> where
    F: Send,
    I: Send,
    ID: Send

impl<I, U, F> Send for FoldWith<I, U, F> where
    F: Send,
    I: Send,
    U: Send

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

impl<I, J> Send for Interleave<I, J>

impl<I, J> Send for InterleaveShortest<I, J>

impl<I> Send for Intersperse<I>

impl<I> Send for MinLen<I>

impl<I> Send for MaxLen<I>

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

impl<I, T, F> Send for MapWith<I, T, F> where
    F: Send,
    T: Send

impl<I, INIT, F> Send for MapInit<I, INIT, F> where
    F: Send,
    INIT: Send

impl<T> Send for MultiZip<T> where
    T: Send

impl<T> Send for Once<T>

impl<I> Send for PanicFuse<I>

impl<Iter> Send for IterBridge<Iter> where
    Iter: Send

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

impl<T> Send for Repeat<T>

impl<T> Send for RepeatN<T>

impl<I> Send for Rev<I>

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

impl<D, S> Send for Split<D, S> where
    D: Send,
    S: Send

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

impl<I, U, ID, F> Send for TryFold<I, U, ID, F> where
    F: Send,
    I: Send,
    ID: Send,
    U: Send

impl<I, U, F> Send for TryFoldWith<I, U, F> where
    F: Send,
    I: Send,
    <U as Try>::Ok: Send

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

impl<I> Send for WhileSome<I>

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

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

impl<I> Send for StepBy<I>

impl<T> Send for IntoIter<T>

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

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

impl<T> Send for Iter<T> where
    T: Send

impl<T> Send for Iter<T> where
    T: Send

impl<T> Send for IntoIter<T>

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

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

impl<'data, T> Send for Iter<'data, T>

impl<'data, T> Send for Chunks<'data, T>

impl<'data, T> Send for ChunksExact<'data, T>

impl<'data, T> Send for Windows<'data, T>

impl<'data, T> Send for IterMut<'data, T>

impl<'data, T> Send for ChunksMut<'data, T>

impl<'data, T> Send for ChunksExactMut<'data, T>

impl<'data, T, P> Send for Split<'data, T, P> where
    P: Send,
    T: Sync

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

impl<'ch> Send for Chars<'ch>

impl<'ch> Send for CharIndices<'ch>

impl<'ch> Send for Bytes<'ch>

impl<'ch> Send for EncodeUtf16<'ch>

impl<'ch, P> Send for Split<'ch, P>

impl<'ch, P> Send for SplitTerminator<'ch, P>

impl<'ch> Send for Lines<'ch>

impl<'ch> Send for SplitWhitespace<'ch>

impl<'ch, P> Send for Matches<'ch, P>

impl<'ch, P> Send for MatchIndices<'ch, P>

impl<'a> Send for Drain<'a>

impl<T> Send for IntoIter<T>

impl<'data, T> Send for Drain<'data, T>

impl<'scope> Send for Scope<'scope>

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

impl Send for ThreadPool

impl<S = DefaultSpawn> !Send for ThreadPoolBuilder<S>

impl !Send for FnContext

impl<T> Send for Set<T> where
    T: Send

impl<T> Send for Range<T> where
    T: Send

impl<TyIx, Ty> Send for TypedIxVec<TyIx, Ty> where
    Ty: Send,
    TyIx: Send

impl Send for InstIx

impl Send for BlockIx

impl Send for RegClass

impl Send for Reg

impl Send for RealReg

impl Send for VirtualReg

impl<R> Send for Writable<R> where
    R: Send

impl Send for SpillSlot

impl<'a> Send for RegUsageCollector<'a>

impl Send for IRSnapshot

impl<F> Send for RegAllocResult<F> where
    <F as Function>::Inst: Send

impl Send for Algorithm

impl Send for Options

impl<'t> Send for Match<'t>

impl Send for Regex

impl<'r, 't> Send for Matches<'r, 't>

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

impl<'r, 't> Send for Split<'r, 't>

impl<'r, 't> Send for SplitN<'r, 't>

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

impl<'t> Send for Captures<'t>

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

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

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

impl Send for RegexSet

impl Send for SetMatches

impl<'a> Send for SetMatchesIter<'a>

impl Send for Error

impl Send for RegexSet

impl Send for SetMatches

impl<'a> Send for SetMatchesIter<'a>

impl<'t> Send for Match<'t>

impl Send for Regex

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

impl<'r, 't> Send for Split<'r, 't>

impl<'r, 't> Send for SplitN<'r, 't>

impl<'t> Send for Captures<'t>

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

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

impl<'r, 't> Send for Matches<'r, 't>

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

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

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

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

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

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

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

impl Send for Builder

impl Send for Error

impl Send for ErrorKind

impl<D> Send for Regex<D> where
    D: Send

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

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

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

impl Send for Parser

impl Send for Printer

impl Send for Error

impl Send for ErrorKind

impl Send for Span

impl Send for Position

impl Send for Comment

impl Send for Ast

impl Send for Alternation

impl Send for Concat

impl Send for Literal

impl Send for LiteralKind

impl Send for Class

impl Send for ClassPerl

impl Send for ClassAscii

impl Send for ClassSet

impl Send for Assertion

impl Send for Repetition

impl Send for Group

impl Send for GroupKind

impl Send for CaptureName

impl Send for SetFlags

impl Send for Flags

impl Send for FlagsItem

impl Send for Flag

impl Send for Error

impl Send for Literals

impl Send for Literal

impl Send for Printer

impl Send for Translator

impl Send for Error

impl Send for ErrorKind

impl Send for Hir

impl Send for HirKind

impl Send for Literal

impl Send for Class

impl<'a> Send for ClassUnicodeIter<'a>

impl Send for ClassBytes

impl<'a> Send for ClassBytesIter<'a>

impl Send for Anchor

impl Send for Group

impl Send for GroupKind

impl Send for Repetition

impl Send for Parser

impl Send for Utf8Range

impl Send for Error

impl Send for Protection

impl Send for TestCase

impl<'a> Send for File<'a>

impl Send for SealingKey

impl Send for OpeningKey

impl Send for Nonce

impl Send for Algorithm

impl<N> Send for OpeningKey<N> where
    N: Send

impl<N> Send for SealingKey<N> where
    N: Send

impl<A> Send for Aad<A> where
    A: Send

impl Send for UnboundKey

impl Send for LessSafeKey

impl Send for Algorithm

impl Send for Tag

impl Send for Algorithm

impl Send for PublicKey

impl<B> Send for UnparsedPublicKey<B> where
    B: Send

impl<'a> Send for Positive<'a>

impl Send for Context

impl Send for Digest

impl Send for Algorithm

impl Send for Unspecified

impl Send for KeyRejected

impl Send for Algorithm

impl Send for Salt

impl Send for Prk

impl<'a, L> Send for Okm<'a, L> where
    L: Send

impl Send for Algorithm

impl Send for Tag

impl Send for Key

impl Send for Context

impl Send for Algorithm

impl Send for Document

impl<T> Send for Random<T> where
    T: Send

impl<B> Send for RsaPublicKeyComponents<B> where
    B: Send

impl Send for RsaKeyPair

impl Send for Signature

impl<B> Send for UnparsedPublicKey<B> where
    B: Send

impl !Send for BackupEngine

impl<'db> !Send for Checkpoint<'db>

impl Send for Decision

impl<F> Send for CompactionFilterCallback<F> where
    F: Send

impl Send for LiveFile

impl<'a, D> Send for DBIteratorWithThreadMode<'a, D>

impl Send for Direction

impl<'a> Send for IteratorMode<'a>

impl !Send for Cache

impl !Send for Env

impl !Send for FlushOptions

impl !Send for DBPath

impl<F, PF> Send for MergeOperatorCallback<F, PF>

impl Send for PerfMetric

impl !Send for PerfContext

impl Send for Error

impl<'a> Send for Demangle<'a>

impl Send for FxHasher

impl<T> Send for ToHexIter<T> where
    T: Send

impl<'a> Send for FromHexIter<'a>

impl Send for Payload

impl Send for PayloadU24

impl Send for PayloadU16

impl Send for PayloadU8

impl<'a> Send for Reader<'a>

impl Send for u24

impl Send for Compression

impl Send for ContentType

impl Send for AlertLevel

impl Send for NamedCurve

impl Send for NamedGroup

impl Send for CipherSuite

impl Send for ECCurveType

impl Send for Random

impl Send for SessionID

impl Send for ServerName

impl Send for Message

impl<'a> Send for BorrowMessage<'a>

impl Send for TLSError

impl<'a, S: ?Sized, T: ?Sized> Send for Stream<'a, S, T> where
    T: Send

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

impl<'a> Send for WriteEarlyData<'a>

impl Send for PrivateKey

impl Send for Certificate

impl Send for NoKeyLog

impl Send for KeyLogFile

impl<'a> Send for ClientHello<'a>

impl Send for Ticketer

impl<S> Send for RwStreamSink<S> where
    S: Send,
    <S as TryStream>::Ok: Send

impl Send for Buffer

impl<R> Send for Salsa<R> where
    R: Send

impl Send for XSalsa20

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

impl<B, Block, C, A> Send for Proposer<B, Block, C, A> where
    B: Send,
    C: Send + Sync

impl<Block, StateBackend> Send for BuiltBlock<Block, StateBackend>

impl<'a, Block, A, B> Send for BlockBuilder<'a, Block, A, B> where
    B: Sync,
    <A as ProvideRuntimeApi<Block>>::Api: Send

impl<G, E> Send for ChainSpec<G, E> where
    E: Send

impl<Block> Send for LightSyncState<Block>

impl<BlockNumber, T> Send for Forks<BlockNumber, T> where
    BlockNumber: Send,
    T: Send,
    <T as Group>::Fork: Send

impl Send for NodeKeyType

impl Send for OutputType

impl Send for RpcMethods

impl Send for Database

impl Send for SignCmd

impl Send for VerifyCmd

impl Send for VanityCmd

impl Send for RevertCmd

impl Send for RunCmd

impl Send for GenerateCmd

impl Send for Error

impl<C> Send for Runner<C> where
    C: Send

impl<Block> Send for ImportSummary<Block>

impl<Block, B> Send for ClientImportOperation<Block, B> where
    <B as Backend<Block>>::BlockImportOperation: Send

impl<'a, State, Block> Send for KeyIterator<'a, State, Block> where
    Block: Send,
    State: Send

impl<Block> Send for ClientInfo<Block>

impl Send for MemorySize

impl Send for MemoryInfo

impl Send for IoInfo

impl Send for UsageInfo

impl<Block> Send for BlockImportNotification<Block>

impl<Block> Send for FinalityNotification<Block>

impl<Block> Send for ExecutionExtensions<Block>

impl<Block> Send for Blockchain<Block>

impl<Block> Send for BlockImportOperation<Block>

impl<Block> Send for Backend<Block>

impl<Header> Send for RemoteCallRequest<Header>

impl<Header> Send for RemoteHeaderRequest<Header>

impl<Header> Send for RemoteReadRequest<Header>

impl<Header> Send for RemoteReadChildRequest<Header>

impl<Header> Send for RemoteChangesRequest<Header>

impl<Header> Send for ChangesProof<Header>

impl<Header> Send for RemoteBodyRequest<Header>

impl<Data, Request> Send for LocalOrRemote<Data, Request> where
    Data: Send,
    Request: Send

impl<H, N> Send for ImportDisplaced<H, N> where
    H: Send,
    N: Send

impl<H, N> Send for FinalizationDisplaced<H, N> where
    H: Send,
    N: Send

impl<H, N> Send for LeafSet<H, N> where
    H: Send,
    N: Send

impl<'a, H, N> Send for Undo<'a, H, N> where
    H: Send,
    N: Send

impl<Block> Send for StorageNotifications<Block>

impl<Block> Send for LightStorage<Block>

impl Send for KeyTracker

impl<B> Send for BenchmarkingState<B>

impl<Block> Send for RefTrackingState<Block>

impl Send for KeepBlocks

impl<Block> Send for BlockchainDb<Block>

impl<Block> Send for BlockImportOperation<Block>

impl<Block> Send for Backend<Block>

impl<B, Block> Send for LongestChain<B, Block> where
    B: Send + Sync,
    Block: Send

impl<C, P, CAW> Send for AuraVerifier<C, P, CAW> where
    C: Send + Sync,
    CAW: Send,
    P: Send

impl<Block, C, I, P> Send for AuraBlockImport<Block, C, I, P> where
    C: Send + Sync,
    I: Send,
    P: Send

impl Send for Epoch

impl<B> Send for Error<B>

impl<B> Send for BabeIntermediate<B>

impl Send for Config

impl<B, C, E, I, SO, SC, CAW, BS> Send for BabeParams<B, C, E, I, SO, SC, CAW, BS> where
    BS: Send,
    C: Send + Sync,
    CAW: Send,
    E: Send,
    I: Send,
    SC: Send,
    SO: Send

impl<B> Send for BabeWorker<B>

impl<Block> Send for BabeLink<Block>

impl<Block, Client, SelectChain, CAW> Send for BabeVerifier<Block, Client, SelectChain, CAW> where
    CAW: Send,
    Client: Send + Sync,
    SelectChain: Send

impl<Block, Client, I> Send for BabeBlockImport<Block, Client, I> where
    Client: Send + Sync,
    I: Send

impl<Hash, Number, E> Send for EpochChangesV0<Hash, Number, E> where
    E: Send,
    Hash: Send,
    Number: Send

impl<H, Block> Send for HeaderBackendDescendentBuilder<H, Block> where
    Block: Send,
    H: Send

impl<E> Send for EpochHeader<E> where
    <E as Epoch>::Slot: Send

impl<Hash, Number> Send for EpochIdentifier<Hash, Number> where
    Hash: Send,
    Number: Send

impl<E, ERef> Send for ViableEpoch<E, ERef> where
    E: Send,
    ERef: Send

impl<Hash, Number, E> Send for ViableEpochDescriptor<Hash, Number, E> where
    Hash: Send,
    Number: Send,
    <E as Epoch>::Slot: Send

impl<E> Send for PersistedEpoch<E> where
    E: Send

impl<E> Send for PersistedEpochHeader<E> where
    <E as Epoch>::Slot: Send

impl<E> Send for IncrementedEpoch<E> where
    E: Send

impl<Hash, Number, E> Send for EpochChanges<Hash, Number, E> where
    E: Send,
    Hash: Send,
    Number: Send,
    <E as Epoch>::Slot: Send

impl Send for SlotInfo

impl<Block> Send for SlotResult<Block>

impl<H, S> Send for CheckedHeader<H, S> where
    H: Send,
    S: Send

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

impl<T> Send for SlotDuration<T> where
    T: Send

impl<N> Send for BackoffAuthoringOnFinalizedHeadLagging<N> where
    N: Send

impl<D> Send for NativeExecutor<D> where
    D: Send

impl Send for Error

impl Send for WasmError

impl<'a, FE> !Send for GuestExternals<'a, FE>

impl<FR> !Send for SandboxInstance<FR>

impl<FR> !Send for UnregisteredInstance<FR>

impl<FR> !Send for Store<FR>

impl<'a> Send for InvokeMethod<'a>

impl<H, N> Send for SharedAuthoritySet<H, N> where
    H: Send + Sync,
    N: Send + Sync

impl<H, N> Send for AuthoritySet<H, N> where
    H: Send,
    N: Send

impl<BE, Block> Send for FinalityProofProvider<BE, Block> where
    BE: Send + Sync

impl<Header> Send for FinalityProof<Header>

impl<Header> Send for WarpSyncFragmentCache<Header>

impl<Backend, Block, Client, SC> Send for GrandpaBlockImport<Backend, Block, Client, SC> where
    Backend: Send,
    Client: Send + Sync,
    SC: Send

impl<Block> Send for GrandpaJustification<Block>

impl<Block> Send for GrandpaJustificationSender<Block>

impl<Block> Send for GrandpaJustificationStream<Block>

impl<N> Send for BeforeBestBlockBy<N> where
    N: Send

impl<Block, B> Send for VotingRulesBuilder<Block, B>

impl Send for Config

impl Send for Error

impl<Block, C, SC> Send for LinkHalf<Block, C, SC> where
    C: Send + Sync,
    SC: Send

impl<Block, C, N, SC, VR> Send for GrandpaParams<Block, C, N, SC, VR> where
    C: Send + Sync,
    N: Send,
    SC: Send,
    VR: Send

impl Send for Error

impl<S, H> Send for Backend<S, H> where
    S: Send + Sync

impl<Block, S> Send for ImportOperation<Block, S> where
    S: Send

impl<S> Send for Blockchain<S> where
    S: Send

impl<B, L> Send for GenesisCallExecutor<B, L> where
    B: Send + Sync,
    L: Send

impl<E, H, B, S> Send for LightDataChecker<E, H, B, S> where
    E: Send,
    H: Send

impl<B> Send for OnDemand<B>

impl Send for DhtEvent

impl Send for Event

impl Send for SyncState

impl<B> Send for PeerInfo<B>

impl<B, H> Send for NetworkService<B, H>

impl<'a> Send for NotificationSenderReady<'a>

impl<B, H> Send for NetworkWorker<B, H>

impl<B> Send for BlockRequestHandler<B>

impl<B> Send for Bitswap<B>

impl Send for OutEvent

impl Send for Response

impl<B> Send for Request<B>

impl<B, H> Send for Params<B, H>

impl Send for Role

impl Send for ProtocolId

impl Send for ParseErr

impl Send for SetConfig

impl<K> Send for Secret<K> where
    K: Send

impl Send for Error

impl<M> Send for QueuedSender<M> where
    M: Send

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

impl Send for Peer

impl<B> Send for NetworkStatus<B>

impl<B> Send for GossipEngine<B>

impl<H> Send for ValidationResult<H> where
    H: Send

impl Send for DiscardAll

impl<Client, Storage, Block> Send for OffchainWorkers<Client, Storage, Block> where
    Client: Send + Sync,
    Storage: Send

impl Send for SetId

impl Send for Message

impl Send for SetConfig

impl Send for Peerset

impl Send for DropReason

impl Send for MetricsLink

impl Send for Metrics

impl<P, Client> Send for Author<P, Client> where
    Client: Send + Sync,
    P: Send + Sync

impl<Block, Client> Send for Chain<Block, Client>

impl<T> Send for Offchain<T>

impl<Block, Client> Send for State<Block, Client>

impl<Block, Client> Send for ChildState<Block, Client>

impl<B> Send for System<B>

impl<B> Send for Request<B>

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

impl Send for Metadata

impl Send for DenyUnsafe

impl Send for Error

impl<Hash> Send for ExtrinsicOrHash<Hash> where
    Hash: Send

impl<Hash, BlockHash> Send for Client<Hash, BlockHash> where
    BlockHash: Send,
    Hash: Send

impl Send for Error

impl<Number, Hash, Header, SignedBlock> Send for Client<Number, Hash, Header, SignedBlock> where
    Hash: Send,
    Header: Send,
    Number: Send,
    SignedBlock: Send

impl Send for Error

impl Send for Client

impl Send for Error

impl<Hash> Send for ReadProof<Hash> where
    Hash: Send

impl<Hash> Send for Client<Hash> where
    Hash: Send

impl<Hash> Send for Client<Hash> where
    Hash: Send

impl Send for Error

impl Send for SystemInfo

impl Send for Health

impl<Hash, Number> Send for PeerInfo<Hash, Number> where
    Hash: Send,
    Number: Send

impl Send for NodeRole

impl<Number> Send for SyncState<Number> where
    Number: Send

impl<Hash, Number> Send for Client<Hash, Number> where
    Hash: Send,
    Number: Send

impl Send for RpcMetrics

impl Send for TaskType

impl Send for RpcMethods

impl Send for BasePath

impl Send for Error

impl<R> Send for NoopRpcExtensionBuilder<R> where
    R: Send

impl<'a, TBl, TCl, TExPool, TRpc, Backend> Send for SpawnTasksParams<'a, TBl, TCl, TExPool, TRpc, Backend> where
    Backend: Send + Sync,
    TCl: Send + Sync,
    TExPool: Send + Sync

impl<'a, TBl, TExPool, TImpQu, TCl> Send for BuildNetworkParams<'a, TBl, TExPool, TImpQu, TCl> where
    TCl: Send + Sync,
    TExPool: Send + Sync,
    TImpQu: Send

impl<B, E> Send for LocalCallExecutor<B, E> where
    B: Send + Sync,
    E: Send

impl Send for TaskManager

impl Send for RpcHandlers

impl<Block> Send for NetworkStatusSinks<Block>

impl<Client, Backend, SelectChain, ImportQueue, TransactionPool, Other> !Send for PartialComponents<Client, Backend, SelectChain, ImportQueue, TransactionPool, Other>

impl Send for RpcSession

impl<C, P> Send for TransactionPoolAdapter<C, P> where
    C: Send + Sync,
    P: Send + Sync

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

impl Send for PinError

impl<H> Send for ChangeSet<H>

impl<H> Send for CommitSet<H>

impl Send for Constraints

impl Send for PruningMode

impl<BlockHash, Key> Send for StateDb<BlockHash, Key>

impl<T> Send for EventFormat<T> where
    T: Send

impl Send for PrefixLayer

impl Send for Error

impl Send for TraceEvent

impl Send for SpanDatum

impl Send for Values

impl Send for Options

impl<B> Send for Pool<B>

impl<Hash, Ex, Error> Send for ValidatedTransaction<Hash, Ex, Error> where
    Error: Send,
    Ex: Send,
    Hash: Send

impl Send for IsValidator

impl<Hash, Ex> Send for Imported<Hash, Ex> where
    Ex: Send + Sync,
    Hash: Send + Sync

impl<Hash, Ex> Send for PruneStatus<Hash, Ex> where
    Ex: Send + Sync,
    Hash: Send + Sync

impl<Hash, Extrinsic> Send for Transaction<Hash, Extrinsic> where
    Extrinsic: Send,
    Hash: Send

impl<Hash, Ex> Send for BasePool<Hash, Ex> where
    Ex: Send + Sync,
    Hash: Send + Sync

impl Send for Limit

impl<H, BH> Send for Watcher<H, BH> where
    BH: Send,
    H: Send

impl<H, BH> Send for Sender<H, BH> where
    BH: Send,
    H: Send

impl<Client, Block> Send for FullChainApi<Client, Block> where
    Block: Send,
    Client: Send + Sync

impl<Client, F, Block> Send for LightChainApi<Client, F, Block> where
    Block: Send,
    Client: Send + Sync,
    F: Send + Sync

impl Send for Error

impl<PoolApi, Block> Send for BasicPool<PoolApi, Block>

impl Send for SecretKey

impl Send for PublicKey

impl Send for Keypair

impl<H> Send for XoFTranscript<H> where
    H: Send

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

impl Send for Signature

impl<T> Send for Malleable<T> where
    T: Send

impl Send for VRFOutput

impl Send for VRFInOut

impl Send for VRFProof

impl Send for ChainCode

impl<K> Send for ExtendedKey<K> where
    K: Send

impl<'a, K> Send for AggregatePublicKeySlice<'a, K> where
    K: Sync

impl Send for Commitment

impl Send for Reveal

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

impl<K> Send for CommitStage<K> where
    K: Send

impl<K> Send for RevealStage<K> where
    K: Send

impl Send for CosignStage

impl Send for Cosignature

impl<T> Send for ScopedKey<T> where
    T: Send

impl Send for Always

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

impl Send for StrCtx

impl Send for Error

impl Send for Endian

impl Send for Uleb128

impl Send for Sleb128

impl<'a> Send for Log<'a>

impl Send for Error

impl Send for Field

impl Send for Affine

impl Send for Jacobian

impl Send for Scalar

impl Send for Error

impl Send for PublicKey

impl Send for SecretKey

impl Send for Signature

impl Send for RecoveryId

impl Send for Message

impl<D> Send for SharedSecret<D>

impl<S> Send for Secret<S> where
    S: Send

impl Send for Error

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

impl<E> Send for BoolDeserializer<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 IsizeDeserializer<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 U64Deserializer<E> where
    E: Send

impl<E> Send for UsizeDeserializer<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 CharDeserializer<E> where
    E: Send

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

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

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

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

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

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

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

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

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

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

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

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

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

impl Send for IgnoredAny

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

impl<Ok, Error> Send for Impossible<Ok, Error> where
    Error: Send,
    Ok: Send

impl<'a> Send for SliceRead<'a>

impl<'a> Send for StrRead<'a>

impl<R> Send for IoRead<R> where
    R: Send

impl<R> Send for Deserializer<R> where
    R: Send

impl<'de, R, T> Send for StreamDeserializer<'de, R, T> where
    R: Send,
    T: Send

impl Send for Error

impl Send for Category

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

impl<'a> Send for Entry<'a>

impl<'a> Send for VacantEntry<'a>

impl<'a> Send for OccupiedEntry<'a>

impl<'a> Send for Iter<'a>

impl<'a> Send for IterMut<'a>

impl Send for IntoIter

impl<'a> Send for Keys<'a>

impl<'a> Send for Values<'a>

impl<'a> Send for ValuesMut<'a>

impl<W, F> Send for Serializer<W, F> where
    F: Send,
    W: Send

impl Send for CharEscape

impl<'a> Send for PrettyFormatter<'a>

impl Send for Serializer

impl Send for Number

impl Send for Value

impl Send for Sha1

impl Send for Sha256

impl Send for Sha224

impl Send for Sha512

impl Send for Sha384

impl Send for Keccak224

impl Send for Keccak256

impl Send for Keccak384

impl Send for Keccak512

impl Send for Sha3_224

impl Send for Sha3_256

impl Send for Sha3_384

impl Send for Sha3_512

impl Send for Shake128

impl Send for Shake256

impl<'a, T, C = DefaultConfig> !Send for Ref<'a, T, C>

impl<'a, T, C = DefaultConfig> !Send for RefMut<'a, T, C>

impl<'a, T, C = DefaultConfig> !Send for Entry<'a, T, C>

impl<'a, T, C = DefaultConfig> !Send for VacantEntry<'a, T, C>

impl Send for Handle

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

impl<E> Send for Pending<E>

impl<O> Send for PollResult<O> where
    O: Send

impl<SD, E> Send for SignalIterator<SD, E> where
    SD: Send

impl Send for SignalOnly

impl<E> Send for SignalsInfo<E>

impl<'a, E> Send for Forever<'a, E>

impl Send for SigId

impl Send for Error

impl<N> Send for AutoSimd<N> where
    N: Send

impl<N> Send for AutoBoolSimd<N> where
    N: Send

impl<V> Send for SimdOption<V> where
    V: Send,
    <V as SimdValue>::SimdBool: Send

impl<T> Send for Slab<T> where
    T: Send

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

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

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

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

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

impl<A> Send for IntoIter<A> where
    <A as Array>::Item: Send

impl Send for Keypair

impl<'builder> Send for Builder<'builder>

impl Send for Error

impl Send for InitStage

impl Send for BaseChoice

impl Send for DHChoice

impl Send for HashChoice

impl Send for NoiseParams

impl Send for SockAddr

impl Send for Socket

impl<'s> Send for SockRef<'s>

impl Send for Domain

impl Send for Type

impl Send for Protocol

impl Send for RecvFlags

impl Send for OpCode

impl Send for Header

impl Send for Codec

impl Send for Error

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

impl Send for Data

impl<'a> Send for ByteSlice125<'a>

impl Send for Deflate

impl<'a> Send for Param<'a>

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

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

impl<'a> Send for ClientRequest<'a>

impl<'a> Send for Response<'a>

impl Send for Error

impl Send for Mode

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

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

impl<T> Send for Builder<T> where
    T: Send

impl Send for Error

impl<T, N> Send for Parsing<T, N> where
    N: Send,
    T: Send

impl<'a> Send for Storage<'a>

impl Send for Error

impl Send for ApiError

impl<'a, Block> !Send for InitializeBlock<'a, Block>

impl<'a, Block, C, NC, Backend> !Send for CallApiAtParams<'a, Block, C, NC, Backend>

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

impl Send for Public

impl Send for Signature

impl Send for Pair

impl Send for Public

impl Send for Signature

impl Send for Pair

impl Send for Public

impl Send for Signature

impl Send for Pair

impl Send for BigUint

impl Send for Percent

impl Send for PerU16

impl Send for Permill

impl Send for Perbill

impl Send for Perquintill

impl Send for FixedI64

impl Send for FixedI128

impl Send for FixedU128

impl Send for Rational128

impl<F, H> Send for InherentDataProvider<F, H> where
    F: Send,
    H: Send

impl<Block> Send for Info<Block>

impl Send for BlockStatus

impl<Block> Send for HashAndNumber<Block>

impl<Block> Send for TreeRoute<Block>

impl<Block> Send for HeaderMetadataCache<Block>

impl<Block> Send for CachedHeaderMetadata<Block>

impl Send for Error

impl Send for ChainType

impl Send for Validation

impl<AuthorityId> Send for OfflineTracker<AuthorityId> where
    AuthorityId: Send

impl Send for Error

impl Send for ImportedAux

impl Send for BlockOrigin

impl<Block> Send for BlockCheckParams<Block>

impl<Block, Transaction> !Send for BlockImportParams<Block, Transaction>

impl<B, Transaction> Send for BasicQueue<B, Transaction> where
    Transaction: Send

impl<B> Send for BufferedLinkSender<B>

impl<B> Send for BufferedLinkReceiver<B>

impl<B> Send for IncomingBlock<B>

impl<N> Send for BlockImportResult<N> where
    N: Send

impl Send for Error

impl Send for BlockStatus

impl<Block, Transaction> Send for Proposal<Block, Transaction> where
    Transaction: Send

impl Send for RecordProof

impl Send for NoNetwork

impl<T> Send for CanAuthorWithNativeVersion<T> where
    T: Send

impl<AuthorityId> Send for ConsensusLog<AuthorityId> where
    AuthorityId: Send

impl Send for PreDigest

impl Send for Epoch

impl Send for Slot

impl<Header, Id> Send for EquivocationProof<Header, Id> where
    Header: Send,
    Id: Send

impl Send for VRFOutput

impl Send for VRFProof

impl<'a> Send for HexDisplay<'a>

impl Send for Dummy

impl Send for Infallible

impl Send for PublicError

impl Send for ParseError

impl Send for AccountId32

impl Send for KeyTypeId

impl Send for _0

impl Send for _1

impl Send for _2

impl Send for _3

impl Send for _4

impl Send for _5

impl Send for _6

impl Send for _7

impl Send for _8

impl Send for _9

impl Send for _10

impl Send for _11

impl Send for _12

impl Send for _13

impl Send for _14

impl Send for _15

impl Send for _16

impl Send for _17

impl Send for _18

impl Send for _19

impl Send for _20

impl Send for _21

impl Send for _22

impl Send for _23

impl Send for _24

impl Send for _25

impl Send for _26

impl Send for _27

impl Send for _28

impl Send for _29

impl Send for _30

impl Send for _31

impl Send for _32

impl Send for _33

impl Send for _34

impl Send for _35

impl Send for _36

impl Send for _37

impl Send for _38

impl Send for _39

impl Send for _40

impl Send for _41

impl Send for _42

impl Send for _43

impl Send for _44

impl Send for _45

impl Send for _46

impl Send for _47

impl Send for _48

impl Send for _49

impl Send for _50

impl Send for _51

impl Send for _52

impl Send for _53

impl Send for _54

impl Send for _55

impl Send for _56

impl Send for _57

impl Send for _58

impl Send for _59

impl Send for _60

impl Send for _61

impl Send for _62

impl Send for _63

impl Send for _64

impl Send for _65

impl Send for _66

impl Send for _67

impl Send for _68

impl Send for _69

impl Send for _70

impl Send for _71

impl Send for _72

impl Send for _73

impl Send for _74

impl Send for _75

impl Send for _76

impl Send for _77

impl Send for _78

impl Send for _79

impl Send for _80

impl Send for _81

impl Send for _82

impl Send for _83

impl Send for _84

impl Send for _85

impl Send for _86

impl Send for _87

impl Send for _88

impl Send for _89

impl Send for _90

impl Send for _91

impl Send for _92

impl Send for _93

impl Send for _94

impl Send for _95

impl Send for _96

impl Send for _97

impl Send for _98

impl Send for _99

impl Send for _100

impl Send for _112

impl Send for _128

impl Send for _160

impl Send for _192

impl Send for _224

impl Send for _256

impl Send for _384

impl Send for _512

impl Send for Public

impl Send for Pair

impl Send for Signature

impl Send for PublicError

impl Send for DeriveError

impl Send for Public

impl Send for Pair

impl Send for Signature

impl Send for Public

impl Send for PublicError

impl Send for Signature

impl Send for DeriveError

impl Send for Pair

impl Send for PoolState

impl Send for StorageKind

impl Send for HttpError

impl Send for Timestamp

impl Send for Duration

impl Send for Capability

impl<T> Send for LimitedExternalities<T> where
    T: Send

impl Send for OffchainExt

impl Send for HostError

impl Send for Entry

impl<Number, Hash> Send for ChangesTrieConfigurationRange<Number, Hash> where
    Hash: Send,
    Number: Send

impl<'a> Send for WrappedRuntimeCode<'a>

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

impl Send for Bytes

impl<R> Send for NativeOrEncoded<R> where
    R: Send

impl Send for LogLevel

impl Send for Void

impl<H> Send for MemDb<H>

impl<H> Send for Change<H> where
    H: Send

impl<'a, H> Send for ChangeRef<'a, H> where
    H: Send

impl<H> Send for Transaction<H> where
    H: Send

impl Send for Extensions

impl Send for Error

impl<N> Send for ScheduledChange<N> where
    N: Send

impl<N> Send for ConsensusLog<N> where
    N: Send

impl<H, N> Send for EquivocationProof<H, N> where
    H: Send,
    N: Send

impl<H, N> Send for Equivocation<H, N> where
    H: Send,
    N: Send

impl<'a> Send for VersionedAuthorityList<'a>

impl Send for Error

impl<E> Send for MakeFatalError<E> where
    E: Send

impl<T> Send for Crossing<T> where
    T: Send

impl Send for Keyring

impl Send for KeyringIter

impl Send for Keyring

impl Send for KeyringIter

impl Send for KeyStore

impl Send for Error

impl Send for KeystoreExt

impl !Send for AbortGuard

impl Send for NumberOrHex

impl<T> Send for ListOrValue<T> where
    T: Send

impl<'a> Send for PiecewiseLinear<'a>

impl<Address, Call, Signature, Extra> Send for UncheckedExtrinsic<Address, Call, Signature, Extra> where
    Address: Send,
    Call: Send,
    Signature: Send

impl<Call, Extra> Send for SignedPayload<Call, Extra> where
    Call: Send,
    <Extra as SignedExtension>::AdditionalSigned: Send

impl Send for Era

impl<AccountId, Call, Extra> Send for CheckedExtrinsic<AccountId, Call, Extra> where
    AccountId: Send,
    Call: Send,
    Extra: Send

impl<Number, Hash> Send for Header<Number, Hash> where
    Number: Send

impl<Block> Send for BlockId<Block>

impl<Header, Extrinsic> Send for Block<Header, Extrinsic> where
    Extrinsic: Send,
    Header: Send

impl<Block> Send for SignedBlock<Block> where
    Block: Send

impl<Hash> Send for Digest<Hash> where
    Hash: Send

impl<Hash> Send for DigestItem<Hash> where
    Hash: Send

impl<'a, Hash> Send for DigestItemRef<'a, Hash> where
    Hash: Sync

impl<'a> Send for OpaqueDigestItemId<'a>

impl Send for Method

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

impl Send for Error

impl Send for Response

impl Send for Headers

impl<'a> Send for HeadersIterator<'a>

impl<'a> Send for StorageValueRef<'a>

impl Send for Time

impl<B> Send for BlockAndTimeDeadline<B> where
    <B as BlockNumberProvider>::BlockNumber: Send

impl<B> Send for BlockAndTime<B> where
    B: Send

impl<'a, L> Send for StorageLock<'a, L> where
    L: Send

impl<'a, 'b, L> Send for StorageLockGuard<'a, 'b, L> where
    L: Send

impl<Xt> Send for ExtrinsicWrapper<Xt> where
    Xt: Send

impl<Xt> Send for Block<Xt> where
    Xt: Send

impl<Call, Extra> Send for TestXt<Call, Extra> where
    Call: Send,
    Extra: Send

impl Send for BadOrigin

impl Send for LookupError

impl<T> Send for IdentityLookup<T> where
    T: Send

impl<AccountId, AccountIndex> Send for AccountIdLookup<AccountId, AccountIndex> where
    AccountId: Send,
    AccountIndex: Send

impl Send for Identity

impl Send for ConvertInto

impl Send for BlakeTwo256

impl Send for Keccak256

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

impl<'a> Send for TrailingZeroInput<'a>

impl<Hashing> Send for RandomNumberGenerator<Hashing>

impl<AccountId, AccountIndex> Send for MultiAddress<AccountId, AccountIndex> where
    AccountId: Send,
    AccountIndex: Send

impl Send for ModuleId

impl Send for MultiSigner

impl<Info> Send for DispatchErrorWithPostInfo<Info> where
    Info: Send

impl<R> Send for TransactionOutcome<R> where
    R: Send

impl<T, O> Send for WrappedFFIValue<T, O> where
    O: Send,
    T: Send

impl<T> Send for ExchangeableFunction<T> where
    T: Send

impl<T> Send for RestoreImplementation<T> where
    T: Send

impl<T> Send for Codec<T> where
    T: Send

impl<T, I> Send for Inner<T, I> where
    I: Send,
    T: Send

impl<T> Send for Enum<T> where
    T: Send

impl<Reporter, Offender> Send for OffenceDetails<Reporter, Offender> where
    Offender: Send,
    Reporter: Send

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

impl<H, N> Send for BuildCache<H, N> where
    H: Send,
    N: Send

impl<H, N> Send for CacheAction<H, N> where
    H: Send,
    N: Send

impl<H, Number> Send for InMemoryStorage<H, Number>

impl<Hash, Number> Send for AnchorBlockId<Hash, Number> where
    Hash: Send

impl<'a, H, Number> Send for State<'a, H, Number> where
    Number: Send

impl<'a, N> Send for ConfigurationRange<'a, N> where
    N: Send

impl<'a, H, N, B> Send for Ext<'a, H, N, B> where
    B: Sync

impl<H, N> Send for TestExternalities<H, N>

impl<Transaction, H, N> Send for StorageChanges<Transaction, H, N> where
    Transaction: Send

impl<Transaction, H, N> Send for StorageTransactionCache<Transaction, H, N> where
    Transaction: Send

impl<'a, S, H> Send for ProvingBackendRecorder<'a, S, H>

impl<'a, S, H> Send for ProvingBackend<'a, S, H>

impl<S, H> Send for TrieBackend<S, H>

impl Send for UsageUnit

impl Send for UsageInfo

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

impl<F> Send for ExecutionManager<F> where
    F: Send

impl<'a, B, H, N, Exec> !Send for StateMachine<'a, B, H, N, Exec>

impl Send for StorageKey

impl Send for StorageData

impl Send for Storage

impl<Hash> Send for StorageChangeSet<Hash> where
    Hash: Send

impl Send for ChildInfo

impl Send for ChildType

impl Send for WasmLevel

impl Send for WasmValue

impl Send for WasmFields

impl Send for Error

impl Send for PoolStatus

impl<Hash, BlockHash> Send for TransactionStatus<Hash, BlockHash> where
    BlockHash: Send,
    Hash: Send

impl<B> Send for ChainEvent<B>

impl Send for Error

impl<H> Send for NodeCodec<H> where
    H: Send

impl Send for TrieStream

impl<H> Send for Layout<H> where
    H: Send

impl<'a, DB, H> Send for KeySpacedDB<'a, DB, H> where
    DB: Sync,
    H: Send

impl<'a, DB, H> Send for KeySpacedDBMut<'a, DB, H> where
    DB: Send,
    H: Send

impl<T> Send for TracingUnboundedSender<T> where
    T: Send

impl<T> Send for TracingUnboundedReceiver<T> where
    T: Send

impl<T> Send for StatusSinks<T> where
    T: Send

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

impl Send for ValueType

impl Send for Value

impl<T> Send for Pointer<T> where
    T: Send

impl Send for Signature

impl Send for ReturnValue

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

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

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

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

impl Send for Bernoulli

impl Send for Beta

impl Send for Binomial

impl Send for Categorical

impl Send for Cauchy

impl Send for Chi

impl Send for ChiSquared

impl Send for Dirac

impl Send for Dirichlet

impl Send for Empirical

impl Send for Erlang

impl Send for Exp

impl Send for Gamma

impl Send for Geometric

impl Send for Laplace

impl Send for LogNormal

impl Send for Multinomial

impl Send for Normal

impl Send for Pareto

impl Send for Poisson

impl Send for StudentsT

impl Send for Triangular

impl Send for Uniform

impl Send for Weibull

impl<D> Send for Data<D> where
    D: Send

impl Send for StatsError

impl Send for LoopError

impl Send for StrSimError

impl Send for ParseError

impl Send for Error

impl<BlockHash, AccountId, Index> Send for Client<BlockHash, AccountId, Index> where
    AccountId: Send,
    BlockHash: Send,
    Index: Send

impl Send for Error

impl<P, C, B> Send for FullSystem<P, C, B> where
    B: Send,
    C: Send + Sync

impl<P, C, F, Block> Send for LightSystem<P, C, F, Block> where
    C: Send + Sync,
    F: Send + Sync

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

impl Send for Choice

impl<T> Send for CtOption<T> where
    T: Send

impl !Send for Underscore

impl !Send for Abstract

impl !Send for As

impl !Send for Async

impl !Send for Auto

impl !Send for Await

impl !Send for Become

impl !Send for Box

impl !Send for Break

impl !Send for Const

impl !Send for Continue

impl !Send for Crate

impl !Send for Default

impl !Send for Do

impl !Send for Dyn

impl !Send for Else

impl !Send for Enum

impl !Send for Extern

impl !Send for Final

impl !Send for Fn

impl !Send for For

impl !Send for If

impl !Send for Impl

impl !Send for In

impl !Send for Let

impl !Send for Loop

impl !Send for Macro

impl !Send for Match

impl !Send for Mod

impl !Send for Move

impl !Send for Mut

impl !Send for Override

impl !Send for Priv

impl !Send for Pub

impl !Send for Ref

impl !Send for Return

impl !Send for SelfType

impl !Send for SelfValue

impl !Send for Static

impl !Send for Struct

impl !Send for Super

impl !Send for Trait

impl !Send for Try

impl !Send for Type

impl !Send for Typeof

impl !Send for Union

impl !Send for Unsafe

impl !Send for Unsized

impl !Send for Use

impl !Send for Virtual

impl !Send for Where

impl !Send for While

impl !Send for Yield

impl !Send for Add

impl !Send for AddEq

impl !Send for And

impl !Send for AndAnd

impl !Send for AndEq

impl !Send for At

impl !Send for Bang

impl !Send for Caret

impl !Send for CaretEq

impl !Send for Colon

impl !Send for Colon2

impl !Send for Comma

impl !Send for Div

impl !Send for DivEq

impl !Send for Dollar

impl !Send for Dot

impl !Send for Dot2

impl !Send for Dot3

impl !Send for DotDotEq

impl !Send for Eq

impl !Send for EqEq

impl !Send for Ge

impl !Send for Gt

impl !Send for Le

impl !Send for Lt

impl !Send for MulEq

impl !Send for Ne

impl !Send for Or

impl !Send for OrEq

impl !Send for OrOr

impl !Send for Pound

impl !Send for Question

impl !Send for RArrow

impl !Send for LArrow

impl !Send for Rem

impl !Send for RemEq

impl !Send for FatArrow

impl !Send for Semi

impl !Send for Shl

impl !Send for ShlEq

impl !Send for Shr

impl !Send for ShrEq

impl !Send for Star

impl !Send for Sub

impl !Send for SubEq

impl !Send for Tilde

impl !Send for Brace

impl !Send for Bracket

impl !Send for Paren

impl !Send for Group

impl !Send for Attribute

impl !Send for AttrStyle

impl !Send for Meta

impl !Send for MetaList

impl !Send for NestedMeta

impl !Send for Variant

impl !Send for Fields

impl !Send for FieldsNamed

impl !Send for Field

impl !Send for Visibility

impl !Send for VisPublic

impl !Send for VisCrate

impl !Send for Expr

impl !Send for ExprArray

impl !Send for ExprAssign

impl !Send for ExprAssignOp

impl !Send for ExprAsync

impl !Send for ExprAwait

impl !Send for ExprBinary

impl !Send for ExprBlock

impl !Send for ExprBox

impl !Send for ExprBreak

impl !Send for ExprCall

impl !Send for ExprCast

impl !Send for ExprClosure

impl !Send for ExprContinue

impl !Send for ExprField

impl !Send for ExprForLoop

impl !Send for ExprGroup

impl !Send for ExprIf

impl !Send for ExprIndex

impl !Send for ExprLet

impl !Send for ExprLit

impl !Send for ExprLoop

impl !Send for ExprMacro

impl !Send for ExprMatch

impl !Send for ExprParen

impl !Send for ExprPath

impl !Send for ExprRange

impl !Send for ExprRepeat

impl !Send for ExprReturn

impl !Send for ExprStruct

impl !Send for ExprTry

impl !Send for ExprTryBlock

impl !Send for ExprTuple

impl !Send for ExprType

impl !Send for ExprUnary

impl !Send for ExprUnsafe

impl !Send for ExprWhile

impl !Send for ExprYield

impl !Send for Member

impl !Send for Index

impl !Send for FieldValue

impl !Send for Label

impl !Send for Arm

impl !Send for RangeLimits

impl !Send for Generics

impl !Send for GenericParam

impl !Send for TypeParam

impl !Send for LifetimeDef

impl !Send for ConstParam

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

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

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

impl !Send for TraitBound

impl !Send for WhereClause

impl !Send for PredicateEq

impl !Send for Item

impl !Send for ItemConst

impl !Send for ItemEnum

impl !Send for ItemFn

impl !Send for ItemImpl

impl !Send for ItemMacro

impl !Send for ItemMacro2

impl !Send for ItemMod

impl !Send for ItemStatic

impl !Send for ItemStruct

impl !Send for ItemTrait

impl !Send for ItemType

impl !Send for ItemUnion

impl !Send for ItemUse

impl !Send for UseTree

impl !Send for UsePath

impl !Send for UseName

impl !Send for UseRename

impl !Send for UseGlob

impl !Send for UseGroup

impl !Send for ForeignItem

impl !Send for TraitItem

impl !Send for ImplItem

impl !Send for ImplItemType

impl !Send for Signature

impl !Send for FnArg

impl !Send for Receiver

impl !Send for File

impl !Send for Lifetime

impl !Send for Lit

impl !Send for LitStr

impl !Send for LitByteStr

impl !Send for LitByte

impl !Send for LitChar

impl !Send for LitInt

impl !Send for LitFloat

impl !Send for LitBool

impl Send for StrStyle

impl !Send for Macro

impl !Send for DeriveInput

impl !Send for Data

impl !Send for DataStruct

impl !Send for DataEnum

impl !Send for DataUnion

impl !Send for BinOp

impl !Send for UnOp

impl !Send for Block

impl !Send for Stmt

impl !Send for Local

impl !Send for Type

impl !Send for TypeArray

impl !Send for TypeBareFn

impl !Send for TypeGroup

impl !Send for TypeInfer

impl !Send for TypeMacro

impl !Send for TypeNever

impl !Send for TypeParen

impl !Send for TypePath

impl !Send for TypePtr

impl !Send for TypeSlice

impl !Send for TypeTuple

impl !Send for Abi

impl !Send for BareFnArg

impl !Send for Variadic

impl !Send for ReturnType

impl !Send for Pat

impl !Send for PatBox

impl !Send for PatIdent

impl !Send for PatLit

impl !Send for PatMacro

impl !Send for PatOr

impl !Send for PatPath

impl !Send for PatRange

impl !Send for PatReference

impl !Send for PatRest

impl !Send for PatSlice

impl !Send for PatStruct

impl !Send for PatTuple

impl !Send for PatType

impl !Send for PatWild

impl !Send for FieldPat

impl !Send for Path

impl !Send for PathSegment

impl !Send for Binding

impl !Send for Constraint

impl !Send for QSelf

impl !Send for TokenBuffer

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

impl<T, P> Send for Punctuated<T, P> where
    P: Send,
    T: Send

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

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

impl<T, P> Send for IntoPairs<T, P> where
    P: Send,
    T: Send

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

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

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

impl<T, P> Send for Pair<T, P> where
    P: Send,
    T: Send

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

impl Send for Error

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

impl<'c, 'a> !Send for StepCursor<'c, 'a>

impl Send for Nothing

impl Send for AddBounds

impl Send for BindStyle

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

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

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

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

impl<'s> Send for Scope<'s>

impl<'c, 'm, T, F> !Send for Hole<'c, 'm, T, F>

impl Send for Size

impl Send for CDataModel

impl Send for ParseError

impl Send for Vendor

impl Send for Environment

impl Send for Endianness

impl Send for Triple

impl Send for TempDir

impl Send for TempPath

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

impl Send for ColorChoice

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

impl Send for Buffer

impl<W> Send for NoColor<W> where
    W: Send

impl<W> Send for Ansi<W> where
    W: Send

impl Send for ColorSpec

impl Send for Color

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

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

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

impl<T> Send for CachedThreadLocal<T>

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

impl<T> Send for CachedIntoIter<T>

impl<T> Send for ThreadLocal<T>

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

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

impl<T> Send for IntoIter<T>

impl Send for Builder

impl Send for ThreadPool

impl Send for Duration

impl Send for Timespec

impl Send for PreciseTime

impl Send for SteadyTime

impl Send for Tm

impl Send for ParseError

impl<'a> Send for TmFmt<'a>

impl Send for Keccak

impl<A> Send for ArrayVec<A> where
    A: Send

impl<'p, A, I> Send for ArrayVecSplice<'p, A, I> where
    A: Send,
    I: Send

impl<A> Send for ArrayVecIterator<A> where
    A: Send

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

impl<'s, T> Send for SliceVec<'s, T> where
    T: Send

impl<'p, 's, T> Send for SliceVecDrain<'p, 's, T> where
    T: Send

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

impl<'p, A> Send for TinyVecDrain<'p, A> where
    <A as Array>::Item: Send

impl<'p, A, I> Send for TinyVecSplice<'p, A, I> where
    A: Send,
    I: Send,
    <A as Array>::Item: Send

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

impl<E> Send for PollEvented<E> where
    E: Send

impl<'a, S: ?Sized> Send for Seek<'a, S> where
    S: Send

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

impl<RW> Send for BufStream<RW> where
    RW: Send

impl<W> Send for BufWriter<W> where
    W: Send

impl<'a, R: ?Sized, W: ?Sized> Send for Copy<'a, R, W> where
    R: Send,
    W: Send

impl Send for Empty

impl<R> Send for Lines<R> where
    R: Send

impl Send for Repeat

impl Send for Sink

impl<R> Send for Split<R> where
    R: Send

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

impl<R> Send for ReaderStream<R> where
    R: Send

impl<R> Send for Take<R> where
    R: Send

impl Send for TcpListener

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

impl<'a> Send for ReadHalf<'a>

impl<'a> Send for WriteHalf<'a>

impl Send for TcpStream

impl Send for JoinError

impl Send for Builder

impl Send for Handle

impl Send for Runtime

impl Send for SignalKind

impl Send for Signal

impl<I> Send for Iter<I> where
    I: Send

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

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

impl Send for Barrier

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

impl Send for RecvError

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

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

impl<T> Send for UnboundedSender<T> where
    T: Send

impl<T> Send for UnboundedReceiver<T> where
    T: Send

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

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

impl Send for RecvError

impl Send for ClosedError

impl<T> Send for SendTimeoutError<T> where
    T: Send

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

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

impl Send for Notify

impl Send for RecvError

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

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

impl Send for Semaphore

impl<'a> Send for SemaphorePermit<'a>

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

impl<T> Send for Receiver<T> where
    T: Send + Sync

impl<T> Send for Sender<T> where
    T: Send + Sync

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

impl<T> Send for DelayQueue<T> where
    T: Send

impl<T> Send for Expired<T> where
    T: Send

impl Send for Key

impl Send for Delay

impl Send for Error

impl Send for Instant

impl Send for Interval

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

impl Send for Elapsed

impl<T> Send for Throttle<T> where
    T: Send

impl Send for BytesCodec

impl Send for LinesCodec

impl !Send for Enter

impl Send for EnterError

impl Send for SpawnError

impl !Send for ParkThread

impl Send for ParkError

impl<R, W> Send for Copy<R, W> where
    R: Send,
    W: Send

impl<A> Send for Flush<A> where
    A: Send

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

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

impl<A> Send for ReadToEnd<A> where
    A: Send

impl<A> Send for ReadUntil<A> where
    A: Send

impl<A> Send for Shutdown<A> where
    A: Send

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

impl<T> Send for AllowStdIo<T> where
    T: Send

impl<A> Send for Lines<A> where
    A: Send

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

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

impl<T> Send for Window<T> where
    T: Send

impl Send for Background

impl Send for Shutdown

impl<E> Send for PollEvented<E> where
    E: Send

impl Send for Reactor

impl Send for Handle

impl Send for Turn

impl<IO> Send for TlsStream<IO> where
    IO: Send

impl<IO> Send for TlsStream<IO> where
    IO: Send

impl Send for TlsAcceptor

impl<IO> Send for Connect<IO> where
    IO: Send

impl<IO> Send for Accept<IO> where
    IO: Send

impl<IO> Send for FailableConnect<IO> where
    IO: Send

impl<IO> Send for FailableAccept<IO> where
    IO: Send

impl<T> Send for TlsStream<T> where
    T: Send

impl<T> Send for LockGuard<T> where
    T: Send

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

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

impl Send for SendError

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

impl Send for RecvError

impl<T> Send for UnboundedSender<T> where
    T: Send

impl<T> Send for UnboundedReceiver<T> where
    T: Send

impl<T> Send for UnboundedTrySendError<T> where
    T: Send

impl Send for RecvError

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

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

impl Send for Permit

impl Send for RecvError

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

impl<T> Send for Receiver<T> where
    T: Send + Sync

impl<T> Send for Sender<T> where
    T: Send + Sync

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

impl<A, C> Send for UnixDatagramFramed<A, C> where
    A: Send,
    C: Send

impl Send for Incoming

impl<T> Send for RecvDgram<T> where
    T: Send

impl<T, P> Send for SendDgram<T, P> where
    P: Send,
    T: Send

impl Send for UnixStream

impl Send for UCred

impl Send for BytesCodec

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

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

impl<T, D> Send for FramedRead<T, D> where
    D: Send,
    T: Send

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

impl Send for Builder

impl Send for LinesCodec

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

impl<'a> Send for Entry<'a>

impl<'a> Send for VacantEntry<'a>

impl<'a> Send for OccupiedEntry<'a>

impl<'a> Send for Iter<'a>

impl<'a> Send for IterMut<'a>

impl Send for IntoIter

impl<'a> Send for Keys<'a>

impl<'a> Send for Values<'a>

impl Send for Datetime

impl Send for Value

impl Send for Error

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

impl Send for Error

impl<'a> Send for Deserializer<'a>

impl<T> Send for Spanned<T> where
    T: Send

impl<T> Send for WithDispatch<T> where
    T: Send

impl<T> Send for Instrumented<T> where
    T: Send

impl Send for Span

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

impl !Send for EnteredSpan

impl Send for Identifier

impl Send for Dispatch

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

impl Send for Field

impl Send for Empty

impl Send for FieldSet

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

impl Send for Iter

impl<T> Send for DisplayValue<T> where
    T: Send

impl<T> Send for DebugValue<T> where
    T: Send

impl<'a> Send for Metadata<'a>

impl Send for Kind

impl Send for Level

impl Send for LevelFilter

impl Send for Id

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

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

impl Send for Current

impl Send for Interest

impl<T> Send for Instrumented<T> where
    T: Send

impl<T> Send for WithDispatch<T> where
    T: Send

impl Send for LogTracer

impl Send for Builder

impl Send for TraceLogger

impl Send for Builder

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

impl<'a> Send for SerializeFieldSet<'a>

impl<'a> Send for SerializeLevel<'a>

impl<'a> Send for SerializeId<'a>

impl<'a> Send for SerializeMetadata<'a>

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

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

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

impl<S> Send for SerdeMapVisitor<S> where
    S: Send,
    <S as SerializeMap>::Error: Send

impl<S> Send for SerdeStructVisitor<S> where
    S: Send,
    <S as SerializeStruct>::Error: Send

impl<V> Send for Alt<V> where
    V: Send

impl<D, V> Send for Delimited<D, V> where
    D: Send,
    V: Send

impl<D, V> Send for VisitDelimited<D, V> where
    D: Send,
    V: Send

impl<V> Send for Messages<V> where
    V: Send

impl Send for Directive

impl Send for ParseError

impl Send for BadName

impl Send for EnvFilter

impl<S, N, E, W> Send for Layer<S, N, E, W> where
    E: Send,
    N: Send,
    S: Send,
    W: Send

impl<E> Send for FormattedFields<E>

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

impl Send for Json

impl Send for JsonFields

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

impl Send for Pretty

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

impl<F> Send for FieldFn<F> where
    F: Send

impl<'a, F> !Send for FieldFnVisitor<'a, F>

impl Send for Compact

impl Send for Full

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

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

impl Send for FmtSpan

impl Send for SystemTime

impl Send for Uptime

impl Send for ChronoUtc

impl Send for ChronoLocal

impl Send for TestWriter

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

impl<M> Send for WithMaxLevel<M> where
    M: Send

impl<M> Send for WithMinLevel<M> where
    M: Send

impl<M, F> Send for WithFilter<M, F> where
    F: Send,
    M: Send

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

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

impl<W> Send for ArcWriter<W> where
    W: Send + Sync

impl<N, E, F, W> Send for Subscriber<N, E, F, W> where
    E: Send,
    F: Send,
    N: Send,
    W: Send

impl<N, E, F, W> Send for SubscriberBuilder<N, E, F, W> where
    E: Send,
    F: Send,
    N: Send,
    W: Send

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

impl<L, I, S> Send for Layered<L, I, S> where
    I: Send,
    L: Send

impl Send for Identity

impl<'a, L> Send for Scope<'a, L> where
    L: Sync,
    <L as LookupSpan<'a>>::Data: Send

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

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

impl Send for Registry

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

impl<'a, R> Send for SpanRef<'a, R> where
    R: Sync,
    <R as LookupSpan<'a>>::Data: Send

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

impl<'a, R> Send for ScopeFromRoot<'a, R> where
    R: Sync,
    <R as LookupSpan<'a>>::Data: Send

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

impl<'a, R> Send for FromRoot<'a, R> where
    R: Sync,
    <R as LookupSpan<'a>>::Data: Send

impl<L, S> Send for Layer<L, S> where
    L: Send + Sync

impl<L, S> Send for Handle<L, S> where
    L: Send + Sync

impl Send for Error

impl Send for CurrentSpan

impl<'a> Send for NodeHandle<'a>

impl<'a> Send for Node<'a>

impl Send for NodePlan

impl<D> Send for OwnedNode<D> where
    D: Send

impl<HO, CE> Send for Error<HO, CE> where
    CE: Send,
    HO: Send

impl<'db, L> !Send for TrieDB<'db, L>

impl<'a, L> !Send for TrieDBIterator<'a, L>

impl<HO> Send for ChildReference<HO> where
    HO: Send

impl<'a, L> Send for TrieDBMut<'a, L>

impl<'db, L> !Send for SecTrieDB<'db, L>

impl<'db, L> Send for SecTrieDBMut<'db, L>

impl<HO> Send for Record<HO> where
    HO: Send

impl<HO> Send for Recorder<HO> where
    HO: Send

impl<'db, L> !Send for FatDB<'db, L>

impl<'db, L> !Send for FatDBIterator<'db, L>

impl<'db, L> Send for FatDBMut<'db, L>

impl<'a, H, HO, V, DB> Send for TrieBuilder<'a, H, HO, V, DB> where
    DB: Send,
    H: Send,
    HO: Send,
    V: Send

impl<H, HO> Send for TrieRoot<H, HO> where
    H: Send,
    HO: Send

impl<H> Send for TrieRootUnhashed<H> where
    H: Send

impl<H, HO> Send for TrieRootPrint<H, HO> where
    H: Send,
    HO: Send

impl<'a, L> !Send for TrieDBNodeIterator<'a, L>

impl<'a, L, Q> !Send for Lookup<'a, L, Q>

impl Send for NibbleVec

impl<'a> Send for NibbleSlice<'a>

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

impl Send for TrieSpec

impl<L> Send for TrieFactory<L> where
    L: Send

impl<'db, L> !Send for TrieKinds<'db, L>

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

impl Send for XxHash64

impl Send for XxHash32

impl Send for Hash64

impl Send for Hash128

impl Send for B0

impl Send for B1

impl<U> Send for PInt<U> where
    U: Send

impl<U> Send for NInt<U> where
    U: Send

impl Send for Z0

impl Send for UTerm

impl<U, B> Send for UInt<U, B> where
    B: Send,
    U: Send

impl Send for ATerm

impl<V, A> Send for TArr<V, A> where
    A: Send,
    V: Send

impl Send for Greater

impl Send for Less

impl Send for Equal

impl Send for Error

impl<'a> Send for TrieSetSlice<'a>

impl<S> Send for UniCase<S> where
    S: Send

impl<S> Send for Ascii<S> where
    S: Send

impl Send for Level

impl Send for Error

impl Send for BidiClass

impl<'text> Send for InitialInfo<'text>

impl<'text> Send for BidiInfo<'text>

impl<I> Send for Decompositions<I> where
    I: Send

impl<I> Send for Recompositions<I> where
    I: Send

impl<I> Send for Replacements<I> where
    I: Send

impl<I> Send for StreamSafe<I> where
    I: Send

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

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

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

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

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

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

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

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

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

impl<U> Send for Output<U>

impl Send for Error

impl Send for Error

impl Send for ReadError

impl<T> Send for Uvi<T> where
    T: Send

impl<T> Send for UviBytes<T> where
    T: Send

impl<'a> Send for Input<'a>

impl<'a> Send for Reader<'a>

impl Send for Mark

impl Send for EndOfInput

impl<S> Send for Host<S> where
    S: Send

impl Send for Origin

impl Send for ParseError

impl<'a> Send for PathSegmentsMut<'a>

impl Send for Position

impl Send for Url

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

impl<'a> Send for UrlQuery<'a>

impl Send for Error

impl<'s, 'f> !Send for Slot<'s, 'f>

impl<'v> !Send for ValueBag<'v>

impl<V> Send for VecMap<V> where
    V: Send

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

impl<'a, V> Send for VacantEntry<'a, V> where
    V: Send

impl<'a, V> Send for OccupiedEntry<'a, V> where
    V: Send

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

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

impl<'a, V> Send for Keys<'a, V> where
    V: Sync

impl<'a, V> Send for Values<'a, V> where
    V: Sync

impl<'a, V> Send for ValuesMut<'a, V> where
    V: Send

impl<V> Send for IntoIter<V> where
    V: Send

impl<'a, V> Send for Drain<'a, V> where
    V: Send

impl Send for Void

impl Send for Giver

impl Send for Taker

impl Send for SharedGiver

impl Send for Closed

impl Send for Wasm64

impl Send for WasmSlice

impl<T> !Send for Closure<T>

impl !Send for JsValue

impl<T> Send for JsStatic<T>

impl<T> Send for Clamped<T> where
    T: Send

impl !Send for Diagnostic

impl !Send for Program

impl !Send for Export

impl Send for MethodSelf

impl !Send for Import

impl !Send for ImportModule

impl !Send for ImportKind

impl !Send for MethodKind

impl !Send for Operation

impl !Send for ImportStatic

impl !Send for ImportType

impl !Send for ImportEnum

impl !Send for Function

impl !Send for Struct

impl !Send for StructField

impl !Send for Enum

impl !Send for Variant

impl Send for TypeKind

impl<T> Send for ShortHash<T> where
    T: Send

impl !Send for JsFuture

impl !Send for BindgenAttrs

impl<F> Send for Timeout<F> where
    F: Send

impl<S> Send for TimeoutStream<S> where
    S: Send

impl Send for Delay

impl Send for Interval

impl Send for Timer

impl Send for TimerHandle

impl !Send for FuncRef

impl !Send for FuncInstance

impl<'args> !Send for FuncInvocation<'args>

impl !Send for GlobalRef

impl<'a> Send for RuntimeArgs<'a>

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

impl !Send for MemoryRef

impl !Send for ModuleRef

impl !Send for ExternVal

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

impl Send for F32

impl Send for F64

impl !Send for TableRef

impl Send for Signature

impl Send for ValueType

impl Send for Error

impl Send for Trap

impl Send for TrapKind

impl Send for Error

impl Send for Module

impl Send for Error

impl<T> Send for StackWithLimit<T> where
    T: Send

impl Send for BlockFrame

impl Send for StartedWith

impl<'a> Send for Locals<'a>

impl Send for Error

impl Send for Range

impl<'a> Send for BinaryReader<'a>

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

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

impl Send for Parser

impl<'a> Send for Chunk<'a>

impl<'a> Send for Payload<'a>

impl<'a> Send for SectionCode<'a>

impl Send for Type

impl<'a> Send for TypeDef<'a>

impl Send for FuncType

impl<'a> Send for InstanceType<'a>

impl<'a> Send for ModuleType<'a>

impl<'a> Send for ExportType<'a>

impl Send for TableType

impl Send for MemoryType

impl Send for EventType

impl Send for GlobalType

impl<'a> Send for Naming<'a>

impl Send for NameType

impl Send for LinkingType

impl Send for RelocType

impl<'a> Send for BrTable<'a>

impl Send for Ieee32

impl Send for Ieee64

impl Send for V128

impl<'a> Send for Operator<'a>

impl<'a> Send for AliasSectionReader<'a>

impl Send for Alias

impl<'a> Send for FunctionBody<'a>

impl<'a> Send for LocalsReader<'a>

impl<'a> Send for CodeSectionReader<'a>

impl<'a> Send for LocalsIterator<'a>

impl<'a> Send for Data<'a>

impl<'a> Send for DataKind<'a>

impl<'a> Send for DataSectionReader<'a>

impl<'a> Send for Element<'a>

impl<'a> Send for ElementKind<'a>

impl<'a> Send for ElementItems<'a>

impl Send for ElementItem

impl<'a> Send for ElementItemsReader<'a>

impl<'a> Send for ElementItemsIterator<'a>

impl<'a> Send for ElementSectionReader<'a>

impl<'a> Send for EventSectionReader<'a>

impl<'a> Send for Export<'a>

impl<'a> Send for ExportSectionReader<'a>

impl<'a> Send for FunctionSectionReader<'a>

impl<'a> Send for Global<'a>

impl<'a> Send for GlobalSectionReader<'a>

impl<'a> Send for Import<'a>

impl<'a> Send for ImportSectionReader<'a>

impl<'a> Send for InitExpr<'a>

impl<'a> Send for InstanceSectionReader<'a>

impl<'a> Send for Instance<'a>

impl<'a> Send for InstanceArgsReader<'a>

impl<'a> Send for LinkingSectionReader<'a>

impl<'a> Send for MemorySectionReader<'a>

impl<'a> Send for ModuleCodeSectionReader<'a>

impl<'a> Send for ModuleCode<'a>

impl<'a> Send for ModuleSectionReader<'a>

impl<'a> Send for ModuleName<'a>

impl<'a> Send for NamingReader<'a>

impl<'a> Send for FunctionName<'a>

impl<'a> Send for FunctionLocalName<'a>

impl<'a> Send for FunctionLocalReader<'a>

impl<'a> Send for LocalName<'a>

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

impl<'a> Send for NameSectionReader<'a>

impl<'a> Send for OperatorsReader<'a>

impl<'a> Send for OperatorsIterator<'a>

impl<'a> Send for ProducersFieldValue<'a>

impl<'a> Send for ProducersField<'a>

impl<'a> Send for ProducersSectionReader<'a>

impl Send for Reloc

impl<'a> Send for RelocSectionReader<'a>

impl<R> Send for SectionIterator<R> where
    R: Send

impl<R> Send for SectionIteratorLimited<R> where
    R: Send

impl<'a> Send for TableSectionReader<'a>

impl<'a> Send for TypeSectionReader<'a>

impl<T> Send for FuncValidator<T> where
    T: Send

impl Send for Validator

impl<'a> Send for ValidPayload<'a>

impl Send for Config

impl Send for Strategy

impl Send for OptLevel

impl Send for Engine

impl !Send for Extern

impl !Send for Global

impl !Send for Table

impl !Send for Memory

impl<'instance> !Send for Export<'instance>

impl Send for FrameInfo

impl Send for FrameSymbol

impl !Send for Func

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

impl !Send for Instance

impl !Send for Linker

impl Send for Module

impl !Send for ExternRef

impl !Send for Store

impl Send for Trap

impl Send for TrapCode

impl Send for Mutability

impl Send for Limits

impl Send for ValType

impl Send for ExternType

impl Send for FuncType

impl Send for GlobalType

impl Send for TableType

impl Send for MemoryType

impl Send for ModuleType

impl<'module> Send for ImportType<'module>

impl<'module> Send for ExportType<'module>

impl !Send for Val

impl Send for CacheConfig

impl<'config> Send for ModuleCacheEntry<'config>

impl Send for Cranelift

impl Send for Relocation

impl Send for MemoryStyle

impl Send for MemoryPlan

impl Send for TableStyle

impl Send for TablePlan

impl Send for ModuleType

impl Send for Module

impl Send for Initializer

impl Send for TypeTables

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

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

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

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

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

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

impl Send for Tunables

impl Send for VMOffsets

impl Send for CodeMemory

impl Send for Compiler

impl Send for Compilation

impl Send for SetupError

impl Send for TypeTables

impl Send for ModuleCode

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

impl Send for VTuneAgent

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

impl !Send for ExportTable

impl !Send for ExportMemory

impl !Send for ExportGlobal

impl !Send for VMExternRef

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

impl Send for LinkError

impl Send for Mmap

impl !Send for Table

impl !Send for TableElement

impl Send for Trap

impl Send for VMContext

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

impl Send for Span

impl<'a> Send for Id<'a>

impl<'a> Send for Index<'a>

impl<'a, K> Send for ItemRef<'a, K> where
    K: Send

impl<'a, K> Send for IndexOrRef<'a, K> where
    K: Send

impl<'a> Send for NameAnnotation<'a>

impl Send for Float32

impl Send for Float64

impl Send for LParen

impl<'a> Send for Alias<'a>

impl<'a> Send for AliasSource<'a>

impl<'a> Send for AssertExpression<'a>

impl<T> Send for NanPattern<T> where
    T: Send

impl Send for V128Pattern

impl<'a> Send for Custom<'a>

impl Send for CustomPlace

impl<'a> Send for Tag<'a>

impl<'a> Send for TagType<'a>

impl<'a> Send for TagKind<'a>

impl<'a> Send for Export<'a>

impl Send for ExportKind

impl<'a> Send for InlineExport<'a>

impl<'a> Send for Expression<'a>

impl<'a> Send for Instruction<'a>

impl<'a> Send for BlockType<'a>

impl<'a> Send for FuncBindType<'a>

impl<'a> Send for LetType<'a>

impl<'a> Send for BrTableIndices<'a>

impl Send for LaneArg

impl<'a> Send for MemArg<'a>

impl<'a> Send for LoadOrStoreLane<'a>

impl<'a> Send for CallIndirect<'a>

impl<'a> Send for TableInit<'a>

impl<'a> Send for TableCopy<'a>

impl<'a> Send for TableArg<'a>

impl<'a> Send for MemoryArg<'a>

impl<'a> Send for MemoryInit<'a>

impl<'a> Send for MemoryCopy<'a>

impl<'a> Send for StructAccess<'a>

impl Send for V128Const

impl<'a> Send for SelectTypes<'a>

impl<'a> Send for Func<'a>

impl<'a> Send for FuncKind<'a>

impl<'a> Send for Local<'a>

impl<'a> Send for Global<'a>

impl<'a> Send for GlobalKind<'a>

impl<'a> Send for Import<'a>

impl<'a> Send for ItemSig<'a>

impl<'a> Send for ItemKind<'a>

impl<'a> Send for InlineImport<'a>

impl<'a> Send for Instance<'a>

impl<'a> Send for InstanceKind<'a>

impl<'a> Send for InstanceArg<'a>

impl<'a> Send for Memory<'a>

impl<'a> Send for MemoryKind<'a>

impl<'a> Send for Data<'a>

impl<'a> Send for DataKind<'a>

impl<'a> Send for DataVal<'a>

impl<'a> Send for Wat<'a>

impl<'a> Send for Module<'a>

impl<'a> Send for ModuleKind<'a>

impl<'a> Send for ModuleField<'a>

impl<'a> Send for NestedModule<'a>

impl<'a> Send for NestedModuleKind<'a>

impl<'a> Send for Table<'a>

impl<'a> Send for TableKind<'a>

impl<'a> Send for Elem<'a>

impl<'a> Send for ElemKind<'a>

impl<'a> Send for ElemPayload<'a>

impl<'a> Send for ValType<'a>

impl<'a> Send for HeapType<'a>

impl<'a> Send for RefType<'a>

impl<'a> Send for StorageType<'a>

impl<'a> Send for GlobalType<'a>

impl Send for Limits

impl Send for Limits64

impl<'a> Send for TableType<'a>

impl Send for MemoryType

impl<'a> Send for FunctionType<'a>

impl<'a> Send for FunctionTypeNoNames<'a>

impl<'a> Send for StructType<'a>

impl<'a> Send for StructField<'a>

impl<'a> Send for ArrayType<'a>

impl<'a> Send for ModuleType<'a>

impl<'a> Send for InstanceType<'a>

impl<'a> Send for ExportType<'a>

impl<'a> Send for TypeDef<'a>

impl<'a> Send for Type<'a>

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

impl<'a> Send for Wast<'a>

impl<'a> Send for WastDirective<'a>

impl<'a> Send for WastExecute<'a>

impl<'a> Send for WastInvoke<'a>

impl<'a> Send for QuoteModule<'a>

impl Send for after

impl Send for alias

impl Send for any

impl Send for anyfunc

impl Send for anyref

impl Send for arg

impl Send for array

impl Send for assert_trap

impl Send for before

impl Send for binary

impl Send for block

impl Send for catch

impl Send for catch_all

impl Send for code

impl Send for data

impl Send for dataref

impl Send for declare

impl Send for delegate

impl Send for do

impl Send for elem

impl Send for end

impl Send for tag

impl Send for export

impl Send for extern

impl Send for externref

impl Send for eq

impl Send for eqref

impl Send for f32

impl Send for f32x4

impl Send for f64

impl Send for f64x2

impl Send for field

impl Send for first

impl Send for func

impl Send for funcref

impl Send for get

impl Send for global

impl Send for i16

impl Send for i16x8

impl Send for i31

impl Send for i31ref

impl Send for i32

impl Send for i32x4

impl Send for i64

impl Send for i64x2

impl Send for i8

impl Send for i8x16

impl Send for import

impl Send for instance

impl Send for instantiate

impl Send for invoke

impl Send for item

impl Send for last

impl Send for local

impl Send for memory

impl Send for module

impl Send for modulecode

impl Send for null

impl Send for nullref

impl Send for offset

impl Send for outer

impl Send for param

impl Send for parent

impl Send for passive

impl Send for quote

impl Send for else

impl Send for if

impl Send for loop

impl Send for mut

impl Send for type

impl Send for ref

impl Send for ref_func

impl Send for ref_null

impl Send for register

impl Send for result

impl Send for rtt

impl Send for shared

impl Send for start

impl Send for struct

impl Send for table

impl Send for then

impl Send for try

impl Send for v128

impl Send for custom

impl Send for name

impl<'a> Send for Lexer<'a>

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

impl Send for LexError

impl Send for SignToken

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

impl<'a> Send for Float<'a>

impl<'a> Send for WasmString<'a>

impl<'a> Send for FloatVal<'a>

impl<'a> Send for ParseBuffer<'a>

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

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

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

impl Send for Error

impl Send for Error

impl Send for Error

impl Send for DNSName

impl<'a> Send for DNSNameRef<'a>

impl Send for Time

impl<'a> Send for EndEntityCert<'a>

impl<'a> Send for TrustAnchor<'a>

impl<'a> Send for TLSServerTrustAnchors<'a>

impl<'a> Send for TLSClientTrustAnchors<'a>

impl<T> Send for AnagolayWeight<T> where
    T: Send

impl<T> Send for Pallet<T> where
    T: Send

impl<T> Send for GenesisConfig<T>

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

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

impl<T> Send for Call<T> where
    T: Send

impl<T> Send for _GeneratedPrefixForStorageVersionByVersionId<T> where
    T: Send

impl<T> Send for _GeneratedPrefixForStorageTotal<T> where
    T: Send

impl<T> Send for FmtBinary<T> where
    T: Send

impl<T> Send for FmtDisplay<T> where
    T: Send

impl<T> Send for FmtLowerExp<T> where
    T: Send

impl<T> Send for FmtLowerHex<T> where
    T: Send

impl<T> Send for FmtOctal<T> where
    T: Send

impl<T> Send for FmtPointer<T> where
    T: Send

impl<T> Send for FmtUpperExp<T> where
    T: Send

impl<T> Send for FmtUpperHex<T> where
    T: Send

impl Send for PublicKey

impl Send for StreamId

impl Send for Control

impl Send for Stream

impl Send for Packet

impl Send for Mode

impl<T> Send for Connection<T> where
    T: Send

impl Send for Config

impl<Z> Send for Zeroizing<Z> where
    Z: Send

impl Send for Compressor

impl<'a> Send for EncoderDictionary<'a>

impl<'a> Send for DecoderDictionary<'a>

impl<R> Send for Decoder<R> where
    R: Send

impl<R> Send for Encoder<R> where
    R: Send

impl<W> Send for Encoder<W> where
    W: Send

impl<W> Send for Decoder<W> where
    W: Send

impl<W> !Send for AutoFinishEncoder<W>

impl<R, D> Send for Reader<R, D> where
    D: Send,
    R: Send

impl<W, D> Send for Writer<W, D> where
    D: Send,
    W: Send

impl Send for NoOp

impl Send for Status

impl Send for Decoder

impl Send for Encoder

impl<'a> Send for InBuffer<'a>

impl<'a> Send for OutBuffer<'a>

impl Send for FrameFormat

impl Send for CParameter

impl Send for DParameter

impl Send for ZSTD_CCtx_s

impl Send for ZSTD_DCtx_s

impl Send for ZSTD_bounds

impl Send for POOL_ctx_s