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.

Implementors§

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

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

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> Send for OnceCell<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 Send for Condvar

impl Send for Runnable

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

impl Send for AtomicWaker

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

impl<T, U> Send for Cow<'_, T, U>where
    U: Capacity,
    T: Beef + Sync + ?Sized,
    T::Owned: Send,

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

impl<L, R, LS, RS> Send for BiHashMap<L, R, LS, RS>where
    L: Send,
    R: Send,
    LS: Send,
    RS: Send,

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

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

impl<T> Send for MisalignError<T>

impl<M, T, O> Send for BitRef<'_, M, T, O>where
    M: Mutability,
    T: BitStore + Sync,
    O: BitOrder,

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

impl<'a, T, O> Send for Iter<'a, T, O>where
    T: BitStore,
    O: BitOrder,
    &'a mut BitSlice<T, O>: Send,

impl<'a, T, O> Send for IterMut<'a, T, O>where
    T: BitStore,
    O: BitOrder,
    &'a mut BitSlice<T, O>: Send,

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

impl<T, O> Send for Drain<'_, T, O>where
    T: BitStore,
    O: BitOrder,
    for<'a> &'a mut BitSlice<T, O>: Send,

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

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 ArrayQueue<T>

impl<T: Send> Send for SegQueue<T>

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 OwnedMutexLockFuture<T>

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

impl<T: ?Sized + Send> Send for OwnedMutexGuard<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> Send for RawTable<T, A>where
    T: Send,
    A: Send + Allocator + Clone,

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

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

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,
    S: 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, 'b, K, Q, V, S, A> Send for OccupiedEntryRef<'a, 'b, K, Q, V, S, A>where
    K: Send,
    Q: Sync + ?Sized,
    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<Block: BlockT, C: CallApiAt<Block>> Send for RuntimeApiImpl<Block, C>

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<'a, K, V> Send for Drain<'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<T> Send for IoVec<T>where
    T: Send,

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<Block: BlockT, C: CallApiAt<Block>> Send for RuntimeApiImpl<Block, C>

impl Send for LockGuard

impl Send for Region

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

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<Block: BlockT, C: CallApiAt<Block>> Send for RuntimeApiImpl<Block, C>

impl Send for Dir

impl<C: Context> Send for Secp256k1<C>

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<T: ?Sized + Send> Send for Mutex<T>

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

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

impl<F, T: Send + Sync> Send for Lazy<T, F>

impl<T: Send> Send for ConstStatic<T>

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

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

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

impl Send for AbortHandle

impl<T: Send> Send for JoinHandle<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<'a, T> Send for MappedMutexGuard<'a, T>where
    T: ?Sized + Send + 'a,

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

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

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

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

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

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

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

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

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

impl<T> Send for Empty<T>

impl<T> Send for Pending<T>

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

impl Send for ExportTable

impl Send for VMExternRef

impl Send for TableElementwhere
    VMExternRef: Send,

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

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

impl Send for Aes192

impl Send for Aes256

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

impl Send for AHasher

impl<K, V, S> Send for AHashMap<K, V, S>where
    K: Send,
    S: Send,
    V: Send,

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

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 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<'a, S> Send for CountingSource<'a, S>where
    S: Send,

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

impl<'a> Send for SliceSink<'a>

impl<'a> Send for VecBacking<'a>

impl<'a> Send for DerObject<'a>

impl<'a> Send for Boolean<'a>

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

impl<'a> Send for Null<'a>

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

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

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

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

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

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

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

impl Send for Zero

impl Send for Stop

impl Send for Constant

impl Send for SystemClock

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

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

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

impl<S, B, N, Fn, Fut> Send for Retry<S, B, N, Fn, Fut>where
    B: Send,
    Fn: Send,
    Fut: Send,
    N: Send,
    S: Send,

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 HexDisplay<'a>

impl Send for Error

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 Extensions

impl Send for Client

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

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

impl Send for Ancestry

impl Send for XcmConfig

impl Send for Alternative

impl Send for Benchmark

impl Send for Benchmark

impl Send for buy

impl Send for set_price

impl Send for make_offer

impl Send for add_royalty

impl Send for Benchmark

impl Send for Benchmark

impl Send for sell

impl Send for buy

impl Send for Benchmark

impl Send for transfer

impl Send for set_balance

impl Send for Benchmark

impl Send for claim

impl Send for Benchmark

impl Send for SessionKeys

impl Send for BaseFilter

impl Send for WeightToFee

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

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

impl Send for Version

impl Send for ItemDeposit

impl Send for KeyLimit

impl Send for ValueLimit

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<Block, Backend, RuntimeApi, I> Send for BeefyBlockImport<Block, Backend, RuntimeApi, I>where
    Backend: Send + Sync,
    I: Send,
    RuntimeApi: Send + Sync,

impl<B> Send for BeefyVoterLinks<B>

impl<B> Send for BeefyRPCLinks<B>

impl<B, BE, C, N, R> Send for BeefyParams<B, BE, C, N, R>where
    R: Send + Sync,

impl Send for Error

impl Send for ErrorCode

impl<Block> Send for Beefy<Block>

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

impl<'a> Send for Leaf<'a>

impl Send for Payload

impl<TBlockNumber> Send for Commitment<TBlockNumber>where
    TBlockNumber: Send,

impl<TBlockNumber, TSignature> Send for SignedCommitment<TBlockNumber, TSignature>where
    TBlockNumber: Send,
    TSignature: Send,

impl<N, S> Send for VersionedFinalityProof<N, S>where
    N: Send,
    S: Send,

impl<BlockNumber, Hash, MerkleRoot, ExtraData> Send for MmrLeaf<BlockNumber, Hash, MerkleRoot, ExtraData>where
    BlockNumber: Send,
    ExtraData: Send,
    Hash: Send,
    MerkleRoot: Send,

impl<MerkleRoot> Send for BeefyAuthoritySet<MerkleRoot>where
    MerkleRoot: Send,

impl<TBlockNumber, TMerkleRoot> Send for SignedCommitmentWitness<TBlockNumber, TMerkleRoot>where
    TBlockNumber: Send,
    TMerkleRoot: Send,

impl Send for Public

impl Send for Signature

impl Send for Pair

impl<AuthorityId> Send for ValidatorSet<AuthorityId>where
    AuthorityId: Send,

impl<AuthorityId> Send for ConsensusLog<AuthorityId>where
    AuthorityId: Send,

impl<Number, Id, Signature> Send for VoteMessage<Number, Id, Signature>where
    Id: Send,
    Number: Send,
    Signature: Send,

impl<L, R> !Send for IntoIter<L, R>

impl<'a, L, R> !Send for Iter<'a, L, R>

impl<'a, L, R> !Send for LeftValues<'a, L, R>

impl<'a, L, R> !Send for RightValues<'a, L, R>

impl<'a, L, R> !Send for LeftRange<'a, L, R>

impl<'a, L, R> !Send for RightRange<'a, L, R>

impl<L, R> !Send for IntoIter<L, R>

impl<'a, L, R> !Send for Iter<'a, L, R>

impl<'a, L, R> !Send for LeftValues<'a, L, R>

impl<'a, L, R> !Send for RightValues<'a, L, R>

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

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<A, O> Send for IntoIter<A, O>where
    A: Send,
    O: Send,

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

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

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

impl<'a, M, T, O> !Send for PartialElement<'a, M, T, O>

impl<R> Send for BitIdx<R>

impl<R> Send for BitIdxError<R>

impl<R> Send for BitEnd<R>

impl<R> Send for BitPos<R>

impl<R> Send for BitSel<R>

impl<R> Send for BitMask<R>

impl Send for Lsb0

impl Send for Msb0

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

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

impl<T> Send for BitPtrError<T>

impl<'a, T, O> !Send for BitValIter<'a, T, O>

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

impl<OutSize> Send for Blake2bMac<OutSize>where
    OutSize: Send,

impl<OutSize> Send for Blake2sMac<OutSize>where
    OutSize: Send,

impl Send for Blake2b

impl Send for Blake2s

impl Send for Params

impl Send for State

impl<'a> Send for HashManyJob<'a>

impl Send for Params

impl Send for State

impl Send for Hash

impl Send for Params

impl Send for State

impl<'a> Send for HashManyJob<'a>

impl Send for Params

impl Send for State

impl Send for Hash

impl Send for Hash

impl Send for HexError

impl Send for Hasher

impl Send for Eager

impl Send for Lazy

impl Send for Error

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

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

impl<T, const L: usize, const U: usize> Send for BoundedVec<T, L, U>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 Send for AllocErr

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

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

impl<'a> !Send for ChunkRawIter<'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 !Send for bz_stream

impl Send for ParseError

impl Send for Reason

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

impl<'a> Send for Lexer<'a>

impl<'a> Send for LexerToken<'a>

impl Send for Func

impl<'a> Send for Predicate<'a>

impl Send for Expression

impl Send for Triple

impl Send for Arch

impl Send for Vendor

impl Send for Os

impl Send for Family

impl Send for Env

impl Send for Panic

impl Send for HasAtomic

impl Send for Families

impl Send for HasAtomics

impl Send for Endian

impl Send for TargetInfo

impl<R, MC> Send for ChaCha<R, MC>where
    MC: Send,
    R: Send,

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

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

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 NaiveWeek

impl Send for NaiveDate

impl Send for IsoWeek

impl Send for NaiveTime

impl Send for FixedOffset

impl Send for Local

impl Send for Utc

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

impl Send for Weekday

impl Send for Month

impl Send for Months

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

impl Send for Error

impl Send for Version

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

impl Send for Error

impl<T, M, S> Send for MMR<T, M, S>where
    M: Send,
    S: Send,
    T: Send,

impl<T, M> Send for MerkleProof<T, M>where
    M: Send,
    T: Send,

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

impl<T, M> Send for MemMMR<T, M>where
    M: Send,
    T: Send,

impl Send for ArgAction

impl Send for AppSettings

impl<'help> Send for Arg<'help>

impl<'help> Send for ArgGroup<'help>

impl Send for ArgSettings

impl<'help> Send for App<'help>

impl<'help> Send for PossibleValue<'help>

impl Send for ValueHint

impl Send for ValueParser

impl<E> Send for EnumValueParser<E>

impl<T> Send for RangedI64ValueParser<T>

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

impl Send for ContextKind

impl Send for ErrorKind

impl Send for Error

impl Send for ArgMatches

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

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

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

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

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

impl Send for ValueSource

impl Send for ColorChoice

impl Send for RawArgs

impl Send for ArgCursor

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

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

impl Send for Clock

impl Send for Duration

impl Send for Instant

impl Send for Updater

impl Send for Cell

impl Send for Cells

impl Send for Column

impl Send for Row

impl Send for Width

impl Send for Table

impl<'a> Send for ColumnCellIter<'a>

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

impl Send for BlockLength

impl Send for SS58Prefix

impl Send for MaxLocks

impl Send for MaxReserves

impl Send for ProxyType

impl Send for MaxProxies

impl Send for MaxPending

impl Send for ExchangeFee

impl Send for MaxInRatio

impl Send for MaxOutRatio

impl Send for MaxVotes

impl Send for SpendPeriod

impl Send for Burn

impl Send for PotId

impl Send for Period

impl Send for Offset

impl Send for LMPalletId

impl Send for DepositBase

impl Send for PopError

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

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

impl Send for Error

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

impl Send for MachTrap

impl Send for MachSrcLoc

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

impl Send for FloatCC

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

impl Send for TrapCode

impl Send for Type

impl Send for ValueLabel

impl Send for Register

impl Send for EvexContext

impl Send for EvexMasking

impl Send for OpcodeMap

impl Send for UnwindInfo

impl Send for UnwindInfo

impl Send for UnwindInfo

impl Send for UnwindInst

impl Send for CallConv

impl Send for LookupError

impl Send for Builder

impl Send for Loop

impl Send for Template

impl Send for Descriptor

impl Send for Detail

impl Send for SettingKind

impl Send for Setting

impl Send for Value

impl Send for Builder

impl Send for SetError

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

impl Send for Flags

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

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

impl Send for Limb

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

impl<const LIMBS: usize> Send for UInt<LIMBS>

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

impl Send for MacError

impl<M> Send for Output<M>

impl Send for Ctr128BE

impl Send for Ctr128LE

impl Send for Ctr32BE

impl Send for Ctr32LE

impl Send for Ctr64BE

impl Send for Ctr64LE

impl<B, F> Send for Ctr<B, F>where
    B: Send,
    F: Send,
    <F as CtrFlavor<<B as BlockCipher>::BlockSize>>::Nonce: Send,

impl Send for CuckooError

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

impl Send for RunCmd

impl<Block, BS, RA> Send for Collator<Block, BS, RA>where
    BS: Send + Sync,
    RA: Send + Sync,

impl<Block, RA, BS, Spawner> Send for StartCollatorParams<Block, RA, BS, Spawner>where
    BS: Send + Sync,
    RA: Send + Sync,
    Spawner: Send,

impl<'a, I, C, CIDP, S, CAW> Send for ImportQueueParams<'a, I, C, CIDP, S, CAW>where
    C: Send + Sync,
    CAW: Send,
    CIDP: Send,
    I: Send,
    S: Sync,

impl<C, CIDP, CAW> Send for BuildVerifierParams<C, CIDP, CAW>where
    C: Send + Sync,
    CAW: Send,
    CIDP: Send,

impl<B, CIDP, W> Send for AuraConsensus<B, CIDP, W>where
    B: Send,
    CIDP: Send + Sync,
    W: Send,

impl<PF, BI, CIDP, Client, BS, SO> Send for BuildAuraConsensusParams<PF, BI, CIDP, Client, BS, SO>where
    BI: Send,
    BS: Send,
    CIDP: Send,
    Client: Send + Sync,
    PF: Send,
    SO: Send,

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

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

impl<Client, Block, CIDP> Send for Verifier<Client, Block, CIDP>where
    Block: Send,
    CIDP: Send,
    Client: Send + Sync,

impl<B, PF, BI, RCInterface, CIDP> Send for RelayChainConsensus<B, PF, BI, RCInterface, CIDP>where
    B: Send,
    BI: Send,
    CIDP: Send + Sync,
    PF: Send,
    RCInterface: Send,

impl<PF, BI, CIDP, RCInterface> Send for BuildRelayChainConsensusParams<PF, BI, CIDP, RCInterface>where
    BI: Send,
    CIDP: Send,
    PF: Send,
    RCInterface: Send,

impl<Block, RCInterface> Send for BlockAnnounceValidator<Block, RCInterface>where
    Block: Send,
    RCInterface: Send,

impl<Block> Send for WaitToAnnounce<Block>

impl<Block, PC, IQ, RC> Send for PoVRecovery<Block, PC, IQ, RC>where
    IQ: Send,
    PC: Send + Sync,
    RC: Send,

impl<'a, Block, BS, Client, RCInterface, Spawner, IQ> Send for StartCollatorParams<'a, Block, BS, Client, RCInterface, Spawner, IQ>where
    BS: Send + Sync,
    Client: Send + Sync,
    IQ: Send,
    RCInterface: Send,
    Spawner: Send,

impl<'a, Block, Client, RCInterface, IQ> Send for StartFullNodeParams<'a, Block, Client, RCInterface, IQ>where
    Client: Send + Sync,
    IQ: Send,
    RCInterface: Send,

impl<Block> Send for SharedImportQueue<Block>

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

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

impl<T, I> Send for BlockExecutor<T, I>where
    I: Send,
    T: Send,

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

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

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

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

impl Send for ConfigData

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

impl<T> Send for RelaychainBlockNumberProvider<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 Event<T>where
    T: Send,

impl Send for Origin

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

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

impl<T> Send for LimitAndDropDmpExecution<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 Event<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 ChannelInfo

impl<B> Send for ParachainBlockData<B>

impl<T, W> Send for ParentAsUmp<T, W>where
    T: Send,
    W: Send,

impl<AccountId, FeeCharger, Matcher, ConcreteAssets, HandleRefund> Send for TakeFirstAssetTrader<AccountId, FeeCharger, Matcher, ConcreteAssets, HandleRefund>where
    AccountId: Send,
    ConcreteAssets: Send,
    FeeCharger: Send,
    HandleRefund: Send,
    Matcher: Send,

impl<FungiblesMutateAdapter, AccountId, ReceiverAccount> Send for XcmFeesTo32ByteAccount<FungiblesMutateAdapter, AccountId, ReceiverAccount>where
    AccountId: Send,
    FungiblesMutateAdapter: Send,
    ReceiverAccount: Send,

impl<Client> Send for RelayChainInProcessInterface<Client>where
    Client: Send + Sync,

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<'a> Send for Any<'a>

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

impl<'a> Send for BitStringIter<'a>

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

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

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

impl<'a> Send for UIntBytes<'a>

impl Send for Null

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

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

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

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

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

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

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

impl Send for UtcTime

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

impl Send for DateTime

impl<'a> Send for Decoder<'a>

impl<'a> Send for Encoder<'a>

impl Send for Error

impl Send for ErrorKind

impl Send for Header

impl Send for Length

impl Send for Class

impl Send for TagMode

impl Send for TagNumber

impl Send for Tag

impl<T, OutSize, O> Send for CtVariableCoreWrapper<T, OutSize, O>where
    O: Send,
    OutSize: Send,
    T: Send,

impl<T> Send for RtVariableCoreWrapper<T>where
    T: Send,
    <T as BufferKindUser>::BufferKind: Send,

impl<T> Send for CoreWrapper<T>where
    T: Send,
    <T as BufferKindUser>::BufferKind: Send,

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

impl Send for TruncSide

impl<T> Send for CtOutput<T>

impl Send for MacError

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 Buffer

impl Send for RecoveryId

impl<C> Send for Signature<C>

impl<C> Send for SigningKey<C>

impl<C> Send for VerifyingKey<C>

impl<C> Send for Signature<C>

impl Send for Signature

impl Send for Keypair

impl Send for PublicKey

impl Send for SecretKey

impl Send for Item

impl Send for Verifier

impl Send for Error

impl Send for Signature

impl Send for SigningKey

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

impl Send for Error

impl<C> Send for ScalarCore<C>

impl<C> Send for NonZeroScalar<C>

impl<C> Send for SecretKey<C>

impl<C> Send for PublicKey<C>

impl<T> Send for FromBitsError<T>where
    T: Send,
    <T as RawBitFlags>::Numeric: Send,

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

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

impl<T> Send for Iter<T>where
    T: Send,
    <T as RawBitFlags>::Numeric: 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 Errno

impl Send for Exit

impl Send for Signal

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

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

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

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

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

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

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

impl<I, U, F> Send for FlatMap<I, U, F>where
    F: Send,
    I: Send,
    <U as IntoFallibleIterator>::IntoFallibleIter: Send,

impl<I> Send for Flatten<I>where
    I: Send,
    <<I as FallibleIterator>::Item as IntoFallibleIterator>::IntoFallibleIter: Send,

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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 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,
    <E as Environment<H, N>>::In: Send,
    <E as Environment<H, N>>::Out: Send,
    <E as Environment<H, N>>::Signature: Send,
    <E as Environment<H, N>>::Timer: Send,

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

impl Send for VoterInfo

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, S, Id> Send for HistoricalVotes<H, N, S, Id>where
    H: Send,
    Id: Send,
    N: Send,
    S: Send,

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

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

impl<Frac> Send for FixedU8<Frac>where
    Frac: Send,

impl<Frac> Send for FixedU16<Frac>where
    Frac: Send,

impl<Frac> Send for FixedU32<Frac>where
    Frac: Send,

impl<Frac> Send for FixedU64<Frac>where
    Frac: Send,

impl<Frac> Send for FixedU128<Frac>where
    Frac: Send,

impl<Frac> Send for FixedI8<Frac>where
    Frac: Send,

impl<Frac> Send for FixedI16<Frac>where
    Frac: Send,

impl<Frac> Send for FixedI32<Frac>where
    Frac: Send,

impl<Frac> Send for FixedI64<Frac>where
    Frac: Send,

impl<Frac> Send for FixedI128<Frac>where
    Frac: Send,

impl Send for F128Bits

impl Send for FixedBitSet

impl<'a> Send for Difference<'a>

impl<'a> Send for SymmetricDifference<'a>

impl<'a> Send for Intersection<'a>

impl<'a> Send for Union<'a>

impl<'a> Send for Ones<'a>

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

impl Send for BlockCmd

impl Send for MachineCmd

impl Send for OverheadCmd

impl Send for PalletCmd

impl Send for StorageCmd

impl Send for Error

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

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

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

impl<VoterIndex, TargetIndex, P> Send for IndexAssignment<VoterIndex, TargetIndex, P>where
    P: Send,
    TargetIndex: Send,
    VoterIndex: Send,

impl<X> Send for NoElection<X>where
    X: Send,

impl<AccountId, Accuracy, Balancing> Send for SequentialPhragmen<AccountId, Accuracy, Balancing>where
    AccountId: Send,
    Accuracy: Send,
    Balancing: Send,

impl<AccountId, Accuracy, Balancing> Send for PhragMMS<AccountId, Accuracy, Balancing>where
    AccountId: Send,
    Accuracy: Send,
    Balancing: Send,

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

impl<T> Send for ExtrinsicMetadata<T>where
    <T as Form>::String: Send,
    <T as Form>::Type: Send,

impl<T> Send for SignedExtensionMetadata<T>where
    <T as Form>::String: Send,
    <T as Form>::Type: Send,

impl<T> Send for PalletMetadata<T>where
    <T as Form>::String: Send,
    <T as Form>::Type: Send,

impl<T> Send for PalletStorageMetadata<T>where
    <T as Form>::String: Send,
    <T as Form>::Type: Send,

impl<T> Send for StorageEntryMetadata<T>where
    <T as Form>::String: Send,
    <T as Form>::Type: Send,

impl<T> Send for StorageEntryType<T>where
    <T as Form>::Type: Send,

impl<T> Send for PalletCallMetadata<T>where
    <T as Form>::Type: Send,

impl<T> Send for PalletEventMetadata<T>where
    <T as Form>::Type: Send,

impl<T> Send for PalletConstantMetadata<T>where
    <T as Form>::String: Send,
    <T as Form>::Type: Send,

impl<T> Send for PalletErrorMetadata<T>where
    <T as Form>::Type: Send,

impl Send for Weight

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

impl Send for Identity

impl Send for Blake2_128

impl Send for Blake2_256

impl Send for Twox128

impl Send for Twox256

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

impl<K, T, H> Send for StorageKeyIterator<K, T, H>where
    H: Send,
    K: Send,
    T: Send,

impl<Prefix, Hasher, Key, Value, QueryKind, OnEmpty, MaxValues> Send for CountedStorageMap<Prefix, Hasher, Key, Value, QueryKind, OnEmpty, MaxValues>where
    Hasher: Send,
    Key: Send,
    MaxValues: Send,
    OnEmpty: Send,
    Prefix: Send,
    QueryKind: Send,
    Value: Send,

impl<Prefix, Hasher1, Key1, Hasher2, Key2, Value, QueryKind, OnEmpty, MaxValues> Send for StorageDoubleMap<Prefix, Hasher1, Key1, Hasher2, Key2, Value, QueryKind, OnEmpty, MaxValues>where
    Hasher1: Send,
    Hasher2: Send,
    Key1: Send,
    Key2: Send,
    MaxValues: Send,
    OnEmpty: Send,
    Prefix: Send,
    QueryKind: Send,
    Value: Send,

impl<Hasher, KeyType> Send for Key<Hasher, KeyType>where
    Hasher: Send,
    KeyType: Send,

impl<Prefix, Hasher, Key, Value, QueryKind, OnEmpty, MaxValues> Send for StorageMap<Prefix, Hasher, Key, Value, QueryKind, OnEmpty, MaxValues>where
    Hasher: Send,
    Key: Send,
    MaxValues: Send,
    OnEmpty: Send,
    Prefix: Send,
    QueryKind: Send,
    Value: Send,

impl<Prefix, Key, Value, QueryKind, OnEmpty, MaxValues> Send for StorageNMap<Prefix, Key, Value, QueryKind, OnEmpty, MaxValues>where
    Key: Send,
    MaxValues: Send,
    OnEmpty: Send,
    Prefix: Send,
    QueryKind: Send,
    Value: Send,

impl<Prefix, Value, QueryKind, OnEmpty> Send for StorageValue<Prefix, Value, QueryKind, OnEmpty>where
    OnEmpty: Send,
    Prefix: Send,
    QueryKind: Send,
    Value: Send,

impl Send for OptionQuery

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

impl Send for ValueQuery

impl<M> Send for KeyLenOf<M>where
    M: Send,

impl<T, OnRemoval> Send for PrefixIterator<T, OnRemoval>where
    OnRemoval: Send,

impl<T> Send for KeyPrefixIterator<T>

impl Send for Instance1

impl Send for Instance2

impl Send for Instance3

impl Send for Instance4

impl Send for Instance5

impl Send for Instance6

impl Send for Instance7

impl Send for Instance8

impl Send for Instance9

impl Send for Instance10

impl Send for Instance11

impl Send for Instance12

impl Send for Instance13

impl Send for Instance14

impl Send for Instance15

impl Send for Instance16

impl<C, A> Send for TotalIssuanceOf<C, A>where
    A: Send,
    C: Send,

impl<B, OnDrop, OppositeOnDrop> Send for Imbalance<B, OnDrop, OppositeOnDrop>where
    B: Send,
    OnDrop: Send,
    OppositeOnDrop: Send,

impl<F, A, AccountId> Send for ItemOf<F, A, AccountId>where
    A: Send,
    AccountId: Send,
    F: Send,

impl<A, B, OnDrop, OppositeOnDrop> Send for Imbalance<A, B, OnDrop, OppositeOnDrop>where
    A: Send,
    B: Send,
    OnDrop: Send,
    OppositeOnDrop: Send,

impl<B, PositiveImbalance> Send for SignedImbalance<B, PositiveImbalance>where
    PositiveImbalance: Send,
    <PositiveImbalance as Imbalance<B>>::Opposite: Send,

impl<Balance, Imbalance, Target1, Target2, const PART1: u32, const PART2: u32> Send for SplitTwoWays<Balance, Imbalance, Target1, Target2, PART1, PART2>where
    Balance: Send,
    Imbalance: Send,
    Target1: Send,
    Target2: Send,

impl<Balance> Send for WithdrawConsequence<Balance>where
    Balance: Send,

impl<F, A, AccountId> Send for ItemOf<F, A, AccountId>where
    A: Send,
    AccountId: Send,
    F: Send,

impl<CP> Send for FromContainsPair<CP>where
    CP: Send,

impl Send for Everything

impl Send for Nothing

impl<Exclude> Send for EverythingBut<Exclude>where
    Exclude: Send,

impl<These, Except> Send for TheseExcept<These, Except>where
    Except: Send,
    These: Send,

impl<These, Those> Send for InsideBoth<These, Those>where
    These: Send,
    Those: Send,

impl<OM> Send for AsContains<OM>where
    OM: Send,

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

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

impl<F, T> Send for ClearFilterGuard<F, T>where
    T: Send,
    <F as FilterStack<T>>::Stack: Send,

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

impl Send for Backing

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

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

impl<S, L, K, T> Send for StorageMapShim<S, L, K, T>where
    K: Send,
    L: Send,
    S: Send,
    T: Send,

impl<BlockNumber> Send for DispatchTime<BlockNumber>where
    BlockNumber: Send,

impl<T, Hash> Send for MaybeHashed<T, Hash>where
    Hash: Send,
    T: Send,

impl Send for LookupError

impl Send for StorageInfo

impl<Success> Send for NeverEnsureOrigin<Success>where
    Success: Send,

impl<EO> Send for AsEnsureOriginWithArg<EO>where
    EO: Send,

impl<Original, Mutator> Send for MapSuccess<Original, Mutator>where
    Mutator: Send,
    Original: Send,

impl<Orig, Mutator> Send for TryMapSuccess<Orig, Mutator>where
    Mutator: Send,
    Orig: Send,

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

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

impl<Tally, Moment, Class> Send for PollStatus<Tally, Moment, Class>where
    Class: Send,
    Moment: Send,
    Tally: Send,

impl<P, T> Send for ClassCountOf<P, T>where
    P: Send,
    T: Send,

impl Send for Select

impl Send for Pays

impl<Balance> Send for WeightToFeeCoefficient<Balance>where
    Balance: Send,

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

impl<T, M> Send for ConstantMultiplier<T, M>where
    M: Send,
    T: Send,

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

impl Send for Never

impl Send for PalletId

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 BlockLength

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<T> Send for CheckGenesis<T>

impl<T> Send for CheckMortality<T>

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

impl<E, T> Send for EventRecord<E, T>where
    T: 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, Success> Send for EnsureRootWithSuccess<AccountId, Success>where
    AccountId: Send,
    Success: 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 Send for RefStatus

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

impl<T> Send for SelfSufficient<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 Pallet<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 !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 LazyConfigAcceptor<IO>where
    IO: Send,

impl<IO> Send for StartHandshake<IO>where
    IO: Send,

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

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

impl<IO> Send for FallibleConnect<IO>where
    IO: Send,

impl<IO> Send for FallibleAccept<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 PollImmediate<T>where
    T: 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>::Error: 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> Send for PeekMut<'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<S> Send for PollImmediate<S>where
    S: 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<T> Send for AllowStdIo<T>where
    T: Send,

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

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

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

impl<W> Send for LineWriter<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<'a, R, W: ?Sized> Send for CopyBufAbortable<'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 Send for FxHasher

impl Send for FxHasher64

impl Send for FxHasher32

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 AArch64

impl Send for RiscV

impl Send for X86

impl Send for X86_64

impl Send for DwSect

impl Send for DwSectV2

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, 'bases, R> Send for EhHdrTableIter<'a, 'bases, R>where
    R: Send + Sync,

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, A> Send for UnwindContext<R, A>where
    R: Send,
    <<A as UnwindContextStorage<R>>::Stack as Sealed>::Storage: Send,

impl<'a, 'ctx, R, A> Send for UnwindTable<'a, 'ctx, R, A>where
    R: Send + Sync,
    <<A as UnwindContextStorage<R>>::Stack as Sealed>::Storage: Send,

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

impl<R, S> Send for UnwindTableRow<R, S>where
    R: Send,
    <<S as UnwindContextStorage<R>>::Rules as Sealed>::Storage: 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> Send for DwarfPackage<R>where
    R: Send,

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 DebugCuIndex<R>where
    R: Send,

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

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

impl<'index, R> Send for UnitIndexSectionIterator<'index, R>where
    R: Send,

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, S> Send for Evaluation<R, S>where
    R: Send,
    <<S as EvaluationStorage<R>>::ExpressionStack as Sealed>::Storage: Send,
    <<S as EvaluationStorage<R>>::Result as Sealed>::Storage: Send,
    <<S as EvaluationStorage<R>>::Stack as Sealed>::Storage: 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<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<T> Send for UnitOffset<T>where
    T: Send,

impl Send for StoreOnHeap

impl Send for Error

impl<Endian> Send for EndianVec<Endian>where
    Endian: Send,

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

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

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

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

impl Send for CieId

impl Send for FrameTable

impl Send for Dwarf

impl Send for DwarfUnit

impl Send for FileId

impl Send for LineProgram

impl Send for LineRow

impl Send for LineString

impl Send for DirectoryId

impl Send for FileInfo

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

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

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

impl Send for Location

impl Send for Expression

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

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

impl Send for RangeListId

impl Send for RangeList

impl Send for Range

impl Send for StringId

impl Send for StringTable

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

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

impl Send for UnitId

impl Send for UnitEntryId

impl Send for UnitTable

impl Send for Unit

impl Send for Attribute

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

impl Send for Error

impl Send for Address

impl Send for Reference

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

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

impl Send for f16

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
    A: Send,
    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
    A: Send,
    K: Send,
    V: Send,

impl<K, V, A> Send for IntoKeys<K, V, A>where
    A: Send,
    K: Send,
    V: Send,

impl<K, V, A> Send for IntoValues<K, V, A>where
    A: Send,
    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: Send + Copy,
    K: Send,
    V: Send,

impl<'a, K, V, F, A> Send for DrainFilter<'a, K, V, F, A>where
    A: Send,
    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
    A: Send,
    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: Send + Sync,
    V: Send,

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

impl<'a, K, V, S, A> Send for RawEntryBuilder<'a, K, V, S, A>where
    A: Sync,
    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
    A: Send,
    K: Send,
    S: Send,
    V: Send,

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

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

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

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

impl<'a, K, A> Send for Drain<'a, K, A>where
    A: Send + Copy,
    K: Send,

impl<'a, K, F, A> Send for DrainFilter<'a, K, F, A>where
    A: Send,
    F: Send,
    K: Send,

impl<'a, T, S, A> Send for Intersection<'a, T, S, A>where
    A: Sync,
    S: Sync,
    T: Sync,

impl<'a, T, S, A> Send for Difference<'a, T, S, A>where
    A: Sync,
    S: Sync,
    T: Sync,

impl<'a, T, S, A> Send for SymmetricDifference<'a, T, S, A>where
    A: Sync,
    S: Sync,
    T: Sync,

impl<'a, T, S, A> Send for Union<'a, T, S, A>where
    A: Sync,
    S: Sync,
    T: Sync,

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

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

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

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

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

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

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

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

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

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

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<D> Send for Empty<D>

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

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

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<D, E> Send for BoxBody<D, E>

impl<D, E> Send for UnsyncBoxBody<D, E>

impl<B, F> Send for MapData<B, F>where
    B: Send,
    F: Send,

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

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<Balance> Send for AssetReserveState<Balance>where
    Balance: Send,

impl<Balance> Send for BalanceUpdate<Balance>where
    Balance: Send,

impl<Balance> Send for AssetStateChange<Balance>where
    Balance: Send,

impl<Balance> Send for TradeStateChange<Balance>where
    Balance: Send,

impl<Balance> Send for HubTradeStateChange<Balance>where
    Balance: Send,

impl<Balance> Send for LiquidityStateChange<Balance>where
    Balance: Send,

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

impl<Balance> Send for I129<Balance>where
    Balance: Send,

impl Send for Ratio

impl Send for Rounding

impl Send for MathError

impl<AccountId, AssetId, Balance, NativeCurrency, MultiCurrency, GetNativeCurrencyId> Send for MultiInspectAdapter<AccountId, AssetId, Balance, NativeCurrency, MultiCurrency, GetNativeCurrencyId>where
    AccountId: Send,
    AssetId: Send,
    Balance: Send,
    GetNativeCurrencyId: Send,
    MultiCurrency: Send,
    NativeCurrency: Send,

impl<AssetId, Balance, Price, ConvertWeightToFee, AcceptedCurrencyPrices, ConvertCurrency, Revenue> Send for MultiCurrencyTrader<AssetId, Balance, Price, ConvertWeightToFee, AcceptedCurrencyPrices, ConvertCurrency, Revenue>where
    AcceptedCurrencyPrices: Send,
    AssetId: Send,
    Balance: Send,
    ConvertCurrency: Send,
    ConvertWeightToFee: Send,
    Price: Send,
    Revenue: Send,

impl<AccountId, AssetId, Balance, Price, C, D, F> Send for ToFeeReceiver<AccountId, AssetId, Balance, Price, C, D, F>where
    AccountId: Send,
    AssetId: Send,
    Balance: Send,
    C: Send,
    D: Send,
    F: Send,
    Price: Send,

impl<AssetId> Send for PoolType<AssetId>where
    AssetId: Send,

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

impl<Balance, BlockNumber, Price> Send for AggregatedEntry<Balance, BlockNumber, Price>where
    Balance: Send,
    BlockNumber: Send,
    Price: Send,

impl<Balance> Send for Volume<Balance>where
    Balance: Send,

impl<Balance> Send for Liquidity<Balance>where
    Balance: Send,

impl<AccountId, AssetId, AssetPair, Balance> Send for AMMTransfer<AccountId, AssetId, AssetPair, Balance>where
    AccountId: Send,
    AssetId: Send,
    AssetPair: Send,
    Balance: Send,

impl Send for Body

impl Send for Sender

impl Send for Error

impl Send for Protocol

impl Send for Upgraded

impl Send for OnUpgrade

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> Send for Client<C, B>where
    B: Send,
    C: Send,

impl Send for Builder

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<C, B, T> Send for Connect<C, B, T>where
    C: Send,

impl<I, F, E> Send for Connecting<I, F, E>where
    E: Send,
    F: Send,
    I: Send,

impl Send for AddrStream

impl<E> Send for Http<E>where
    E: 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<State> Send for ConnectorBuilder<State>where
    State: 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<K, V> Send for IntoKeys<K, V>where
    K: Send,
    V: Send,

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

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

impl<K, V> Send for IntoValues<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<'inp, 'out, T> !Send for InOut<'inp, 'out, T>

impl<'inp, 'out, T> !Send for InOutBuf<'inp, 'out, T>

impl<'inp, 'out, T> !Send for InOutBufIter<'inp, 'out, T>

impl<'inp, 'out, T> !Send for InOutBufReserved<'inp, 'out, T>

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

impl<AccountId> Send for TinkernetMultisigAccountIdDeriver<AccountId>where
    AccountId: Send,

impl<Origin> Send for TinkernetMultisigSignedDeriver<Origin>where
    Origin: Send,

impl<AccountId, Deriver> Send for PalletInstanceGeneralIndexAsAccountId<AccountId, Deriver>where
    AccountId: Send,
    Deriver: Send,

impl<Origin, Deriver> Send for DeriveOriginFromPalletInstanceGeneralIndex<Origin, Deriver>where
    Deriver: Send,
    Origin: Send,

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

impl Send for OwnedFd

impl<'filelike, Target> Send for FilelikeView<'filelike, Target>where
    Target: Send,

impl<'socketlike, Target> Send for SocketlikeView<'socketlike, Target>where
    Target: Send,

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

impl<I, F> Send for FilterOk<I, F>where
    F: Send,
    I: 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, 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, T> Send for TupleCombinations<I, T>where
    I: 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, T, E> Send for FlattenOk<I, T, E>where
    I: Send,
    <T as IntoIterator>::IntoIter: Send,

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

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

impl<'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, ElemF> Send for IntersperseWith<I, ElemF>where
    ElemF: Send,
    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> Send for PeekNth<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 Powerset<I>where
    I: Send,
    <I as Iterator>::Item: Send,

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

impl<I> !Send for 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 CircularTupleWindows<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 BigInt

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

impl Send for Receiver

impl Send for Mode

impl Send for WsError

impl Send for Target

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

impl Send for Error

impl Send for Origin

impl Send for AllowOrigin

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

impl Send for Port

impl Send for Host

impl Send for AllowHosts

impl Send for MethodSink

impl Send for Resources

impl<'a> Send for ConnState<'a>

impl Send for MethodKind

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

impl<'a> Send for MethodResourcesBuilder<'a>

impl Send for Methods

impl<Context> Send for RpcModule<Context>where
    Context: Send + Sync,

impl Send for MethodKind

impl Send for Client

impl<Notif> Send for Subscription<Notif>where
    Notif: Send,

impl Send for FrontToBack

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

impl Send for IdKind

impl Send for RpcTracing

impl<M> Send for Builder<M>where
    M: Send,

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

impl<'a> Send for Params<'a>

impl<'a> Send for ParamsSequence<'a>

impl<'a> Send for ParamsSer<'a>

impl<'a> Send for SubscriptionId<'a>

impl<'a> Send for Id<'a>

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

impl<'a> Send for InvalidRequest<'a>

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

impl<'a> Send for RequestSer<'a>

impl<'a> Send for NotificationSer<'a>

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

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

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

impl<'a> Send for ErrorResponse<'a>

impl<'a> Send for ErrorObject<'a>

impl Send for ErrorCode

impl Send for CallError

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

impl<M> Send for Builder<M>where
    M: Send,

impl Send for AffinePoint

impl Send for Scalar

impl Send for Signature

impl Send for Id

impl Send for SigningKey

impl Send for Secp256k1

impl Send for KsmLocation

impl Send for Ancestry

impl Send for Kusama

impl Send for Statemine

impl Send for XcmConfig

impl Send for MaxVotes

impl Send for MaxVoters

impl Send for BaseFilter

impl Send for Version

impl Send for SS58Prefix

impl Send for MaxLocks

impl Send for MaxReserves

impl Send for Period

impl Send for Offset

impl Send for SessionKeys

impl Send for SignedPhase

impl Send for EraPayout

impl Send for SpendPeriod

impl Send for Burn

impl Send for MaxKeys

impl Send for Prefix

impl Send for DepositBase

impl Send for MaxFriends

impl Send for MaxStrikes

impl Send for PeriodSpend

impl Send for MaxProxies

impl Send for MaxPending

impl Send for ProxyType

impl Send for ParaDeposit

impl Send for LeasePeriod

impl Send for CrowdloanId

impl Send for QueueCount

impl Send for MaxQueueLen

impl Send for GiltPeriod

impl Send for MinFreeze

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 WeightToFee

impl Send for Kind

impl Send for IoStats

impl Send for DBOp

impl Send for InMemory

impl Send for Database

impl Send for statvfs

impl Send for max_align_t

impl Send for clone_args

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

impl Send for nl_mmap_req

impl Send for nl_mmap_hdr

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 termios2

impl Send for open_how

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 nlmsghdr

impl Send for nlmsgerr

impl Send for nlattr

impl Send for in6_ifreq

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 ifreq

impl Send for sock_txtime

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 ip_mreqn

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

impl Send for NatStatus

impl Send for ProbeId

impl Send for Event

impl Send for Behaviour

impl Send for PeerId

impl Send for Endpoint

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

impl<T, C> Send for AndThen<T, C>where
    C: Send,
    T: 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 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 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<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<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 Send for ListenerId

impl<TUpgr, TErr> Send for TransportEvent<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, C, P> Send for GenDnsConfig<T, C, P>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 Send for Config

impl Send for Metrics

impl Send for Inclusion

impl Send for Churn

impl Send for Penalty

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 MdnsConfig

impl Send for MplexConfig

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

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

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 Config

impl Send for Success

impl Send for Failure

impl Send for Behaviour

impl Send for Event

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

impl Send for Reservation

impl Send for Event

impl Send for Client

impl<Id> Send for RateLimiter<Id>where
    Id: Send,

impl Send for Config

impl Send for Event

impl Send for Relay

impl Send for CircuitId

impl Send for RequestId

impl Send for Namespace

impl Send for Cookie

impl Send for ErrorCode

impl Send for Behaviour

impl Send for Event

impl Send for Behaviour

impl Send for Config

impl Send for Event

impl<TCodec> Send for ResponseProtocol<TCodec>where
    TCodec: Send,

impl<TCodec> Send for RequestProtocol<TCodec>where
    TCodec: 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>

impl<THandlerErr> Send for ConnectionError<THandlerErr>where
    THandlerErr: Send,

impl<TTransErr> Send for PendingConnectionError<TTransErr>where
    TTransErr: Send,

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

impl<TBehaviour> Send for Toggle<TBehaviour>where
    TBehaviour: Send,

impl<TInner> Send for ToggleIntoConnectionHandler<TInner>where
    TInner: Send,

impl<TInner> Send for ToggleConnectionHandler<TInner>where
    TInner: Send,

impl<TOutEvent, THandler, TInEvent> Send for NetworkBehaviourAction<TOutEvent, THandler, TInEvent>where
    TInEvent: Send,
    TOutEvent: Send,

impl Send for DialOpts

impl Send for WithPeerId

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

impl<TConnectionHandler, TNewIn, TMap> Send for MapInEvent<TConnectionHandler, TNewIn, TMap>where
    TConnectionHandler: Send,
    TMap: Send,
    TNewIn: Send,

impl<TConnectionHandler, TMap> Send for MapOutEvent<TConnectionHandler, TMap>where
    TConnectionHandler: Send,
    TMap: 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<TInbound, TOutbound, TEvent> Send for OneShotHandler<TInbound, TOutbound, TEvent>where
    TEvent: Send,
    TInbound: Send,

impl<TProto1, TProto2> Send for IntoConnectionHandlerSelect<TProto1, TProto2>where
    TProto1: Send,
    TProto2: Send,

impl<TProto1, TProto2> Send for ConnectionHandlerSelect<TProto1, TProto2>where
    TProto1: Send,
    TProto2: Send,

impl<TUpgrade, TInfo> Send for SubstreamProtocol<TUpgrade, TInfo>where
    TInfo: Send,
    TUpgrade: Send,

impl<TConnectionUpgrade, TOutboundOpenInfo, TCustom, TErr> Send for ConnectionHandlerEvent<TConnectionUpgrade, TOutboundOpenInfo, TCustom, TErr>where
    TConnectionUpgrade: Send,
    TCustom: Send,
    TErr: Send,
    TOutboundOpenInfo: Send,

impl<TUpgrErr> Send for ConnectionHandlerUpgrErr<TUpgrErr>where
    TUpgrErr: Send,

impl Send for KeepAlive

impl<TBehaviourOutEvent, THandlerErr> Send for SwarmEvent<TBehaviourOutEvent, THandlerErr>where
    TBehaviourOutEvent: Send,
    THandlerErr: Send,

impl<TBehaviour> Send for Swarm<TBehaviour>where
    TBehaviour: Send,

impl<'a> Send for SwarmPollParameters<'a>

impl<TBehaviour> Send for SwarmBuilder<TBehaviour>where
    TBehaviour: Send,

impl Send for DialError

impl Send for NetworkInfo

impl Send for Tcp

impl<T> Send for GenTcpTransport<T>

impl<S> Send for TcpListenerEvent<S>where
    S: 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 Incoming

impl Send for Data

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 PublicKey

impl Send for SecretKey

impl Send for Signature

impl Send for RecoveryId

impl Send for Message

impl<D> Send for SharedSecret<D>

impl Send for Field

impl Send for Affine

impl Send for Jacobian

impl<'a> Send for Decoder<'a>

impl Send for Error

impl Send for Scalar

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<Storage> Send for __BindgenBitfieldUnit<Storage>where
    Storage: Send,

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

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

impl Send for f_owner_ex

impl Send for flock

impl Send for flock64

impl Send for open_how

impl Send for epoll_event

impl Send for fscrypt_key

impl Send for mount_attr

impl Send for fsxattr

impl Send for futex_waitv

impl !Send for robust_list

impl Send for in_addr

impl Send for ip_mreq

impl Send for ip_mreqn

impl Send for ip_msfilter

impl !Send for group_req

impl !Send for group_filter

impl Send for in_pktinfo

impl Send for sockaddr_in

impl Send for iphdr

impl Send for ip_auth_hdr

impl Send for ip_esp_hdr

impl Send for ip_comp_hdr

impl Send for in6_addr

impl Send for ipv6_mreq

impl Send for in6_pktinfo

impl Send for ip6_mtuinfo

impl Send for in6_ifreq

impl Send for ipv6_rt_hdr

impl Send for rt0_hdr

impl Send for rt2_hdr

impl Send for ipv6hdr

impl Send for pollfd

impl !Send for prctl_mm_map

impl Send for timespec

impl Send for timeval

impl Send for itimerspec

impl Send for itimerval

impl Send for timezone

impl Send for rusage

impl Send for rlimit

impl Send for rlimit64

impl Send for clone_args

impl Send for sigaction

impl !Send for sigaltstack

impl !Send for sigval

impl !Send for __sifields

impl !Send for siginfo

impl !Send for sigevent

impl Send for statx

impl Send for tcphdr

impl Send for tcp_info

impl !Send for tcp_md5sig

impl Send for termios

impl Send for termios2

impl Send for ktermios

impl Send for winsize

impl Send for termio

impl !Send for iovec

impl Send for sockaddr_un

impl Send for old_utsname

impl Send for new_utsname

impl Send for uffd_msg

impl Send for uffdio_api

impl Send for uffdio_copy

impl !Send for sockaddr

impl Send for linger

impl Send for stat

impl Send for statfs

impl Send for statfs64

impl Send for user_desc

impl !Send for msghdr

impl Send for cmsghdr

impl Send for ucred

impl !Send for mmsghdr

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<K, V> Send for IntoIter<K, V>where
    K: Send,
    V: Send,

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

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

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

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

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

impl Send for BlockSize

impl Send for BlockMode

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 Error

impl Send for HugetlbSize

impl Send for Memfd

impl Send for FileSeal

impl Send for Advice

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<K, V> Send for MemoryLruCache<K, V>where
    K: Send,
    V: Send,

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 Config

impl Send for TracesIn

impl Send for Span

impl Send for StartTime

impl<'a> Send for Log<'a>

impl Send for TracesOut

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 Interest

impl Send for Poll

impl Send for Registry

impl<'a> Send for SourceFd<'a>

impl Send for SocketAddr

impl Send for Sender

impl Send for Receiver

impl Send for Token

impl Send for Waker

impl Send for Event

impl Send for Events

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

impl Send for TcpListener

impl Send for TcpStream

impl Send for UdpSocket

impl Send for UnixStream

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

impl Send for Error

impl Send for Error

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

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

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

impl Send for Sha2_256

impl Send for Sha2_512

impl Send for Sha3_224

impl Send for Sha3_256

impl Send for Sha3_384

impl Send for Sha3_512

impl Send for Keccak224

impl Send for Keccak256

impl Send for Keccak384

impl Send for Keccak512

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

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

impl Send for Code

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 WyRand

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

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

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

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

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

impl Send for CacheInfo

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

impl Send for Nla

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

impl Send for LinkHeader

impl Send for LinkMessage

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

impl Send for InetDevConf

impl Send for Inet

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

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

impl Send for Icmp6Stats

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

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

impl Send for Inet6Stats

impl Send for Inet6

impl Send for AfSpecInet

impl Send for Info

impl Send for InfoData

impl Send for InfoKind

impl Send for InfoVxlan

impl Send for InfoVlan

impl Send for InfoBridge

impl Send for InfoIpoib

impl Send for VethInfo

impl Send for InfoIpVlan

impl Send for InfoVrf

impl Send for InfoMacVlan

impl Send for InfoMacVtap

impl Send for Prop

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

impl Send for Map

impl Send for Stats

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

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

impl Send for Stats64

impl Send for State

impl Send for Nla

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

impl Send for CacheInfo

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

impl Send for Nla

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

impl Send for Config

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

impl Send for Stats

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

impl Send for Nla

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

impl Send for NsidHeader

impl Send for NsidMessage

impl Send for Nla

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

impl Send for RouteFlags

impl Send for RouteHeader

impl Send for CacheInfo

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

impl Send for Metrics

impl Send for MfcStats

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

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

impl Send for NextHop

impl Send for Nla

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

impl Send for RuleFlags

impl Send for RuleHeader

impl Send for RuleMessage

impl Send for Nla

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

impl Send for TcMessage

impl Send for TcHeader

impl Send for Stats

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

impl Send for StatsQueue

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

impl Send for StatsBasic

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

impl Send for TcOpt

impl Send for Nla

impl Send for Sel

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

impl Send for Key

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

impl Send for Nla

impl Send for TcMirred

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

impl Send for Action

impl Send for ActNla

impl Send for ActOpt

impl Send for TcGen

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

impl Send for Nla

impl Send for Stats2

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

impl Send for RtnlMessage

impl Send for EncodeError

impl Send for DecodeError

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

impl Send for DefaultNla

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

impl<T, S, C> Send for NetlinkFramed<T, S, C>where
    S: Send,

impl<T, S, C> Send for Connection<T, S, C>where
    S: Send,
    T: Send,

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

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

impl Send for Socket

impl Send for SocketAddr

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

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

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

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

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

impl Send for SmolSocket

impl Send for Errno

impl Send for AtFlags

impl Send for OFlag

impl Send for RenameFlags

impl Send for SealFlag

impl Send for FdFlag

impl<'a> Send for FcntlArg<'a>

impl Send for FlockArg

impl Send for MsFlags

impl Send for MntFlags

impl Send for CloneFlags

impl Send for CpuSet

impl !Send for SigEvent

impl Send for Signal

impl Send for SaFlags

impl Send for SigmaskHow

impl Send for SigSet

impl<'a> Send for SigSetIter<'a>

impl Send for SigHandler

impl Send for SigAction

impl Send for SigevNotify

impl Send for SfdFlags

impl Send for SignalFd

impl Send for SFlag

impl Send for Mode

impl Send for Statfs

impl Send for FsType

impl Send for FsFlags

impl Send for Statvfs

impl Send for SysInfo

impl Send for TimeSpec

impl Send for TimeVal

impl Send for RemoteIoVec

impl Send for WaitPidFlag

impl Send for WaitStatus

impl Send for Id

impl Send for Pid

impl Send for ForkResult

impl Send for Whence

impl Send for LinkatFlags

impl Send for AccessFlags

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

impl Send for Error

impl Send for ErrorKind

impl Send for Grouping

impl Send for Locale

impl<'a> Send for DecimalStr<'a>

impl<'a> Send for InfinityStr<'a>

impl<'a> Send for MinusSignStr<'a>

impl<'a> Send for NanStr<'a>

impl<'a> Send for PlusSignStr<'a>

impl<'a> Send for SeparatorStr<'a>

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> Send for Version<'data>

impl<'data, Elf> Send for VersionTable<'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, E, R> Send for DyldSubCache<'data, E, R>where
    E: Sync,
    R: Send,

impl<'data, 'cache, E, R> Send for DyldCacheImageIterator<'data, 'cache, E, R>where
    E: Sync,
    R: Sync,

impl<'data, 'cache, E, R> Send for DyldCacheImage<'data, 'cache, E, R>where
    E: Sync,
    R: Sync,

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,
    <Mach as MachHeader>::Segment: 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,
    <Mach as MachHeader>::Segment: 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,
    <Mach as MachHeader>::Segment: 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,
    <Mach as MachHeader>::Segment: 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: Sync,
    <Mach as MachHeader>::Nlist: Sync,
    <Mach as MachHeader>::Section: Sync,
    <Mach as MachHeader>::Segment: 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,
    <Mach as MachHeader>::Segment: 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,
    <Mach as MachHeader>::Segment: 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,
    <Mach as MachHeader>::Segment: 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,
    <Mach as MachHeader>::Segment: 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,
    <Mach as MachHeader>::Segment: 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,
    <Mach as MachHeader>::Segment: 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<'data> Send for DataDirectories<'data>

impl<'data> Send for ExportTarget<'data>

impl<'data> Send for Export<'data>

impl<'data> Send for ExportTable<'data>

impl<'data> Send for ImportTable<'data>

impl<'data> Send for ImportDescriptorIterator<'data>

impl<'data> Send for ImportThunkList<'data>

impl<'data> Send for Import<'data>

impl<'data> Send for RelocationBlockIterator<'data>

impl<'data> Send for RelocationIterator<'data>

impl Send for Relocation

impl<'data> Send for ResourceDirectory<'data>

impl<'data> Send for ResourceDirectoryTable<'data>

impl<'data> Send for ResourceDirectoryEntryData<'data>

impl<'data> Send for RichHeaderInfo<'data>

impl Send for Error

impl Send for FileKind

impl Send for ObjectKind

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<E> Send for DyldSubCacheInfo<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 Send for ToOrchestra

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

impl<E> Send for SpawnedSubsystem<E>

impl<Message, Signal> Send for SubsystemInstance<Message, Signal>where
    Message: Send,
    Signal: Send,

impl<Message, Signal> Send for FromOrchestra<Message, Signal>where
    Message: Send,
    Signal: Send,

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

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

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

impl Send for FloatIsNan

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

impl<T, GetCurrencyId> Send for PositiveImbalance<T, GetCurrencyId>where
    GetCurrencyId: Send,

impl<T, GetCurrencyId> Send for NegativeImbalance<T, GetCurrencyId>where
    GetCurrencyId: Send,

impl<AccountId, TestKey, A, B> Send for Combiner<AccountId, TestKey, A, B>where
    A: Send,
    AccountId: Send,
    B: Send,
    TestKey: Send,

impl<AccountId, T, C, B, GetCurrencyId> Send for Mapper<AccountId, T, C, B, GetCurrencyId>where
    AccountId: Send,
    B: Send,
    C: Send,
    GetCurrencyId: Send,
    T: Send,

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

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

impl<T> Send for GenesisConfig<T>

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

impl<T> Send for Call<T>where
    T: Send,
    <<T as Config>::Lookup as StaticLookup>::Source: Send,

impl<T, GetAccountId> Send for TransferDust<T, GetAccountId>where
    GetAccountId: Send,
    T: Send,

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

impl<Balance> Send for BalanceLock<Balance>where
    Balance: Send,

impl<ReserveIdentifier, Balance> Send for ReserveData<ReserveIdentifier, Balance>where
    Balance: Send,
    ReserveIdentifier: Send,

impl<Balance> Send for AccountData<Balance>where
    Balance: Send,

impl<T, GetCurrencyId> Send for CurrencyAdapter<T, GetCurrencyId>where
    GetCurrencyId: Send,
    T: Send,

impl<Balance, CustomMetadata> Send for AssetMetadata<Balance, CustomMetadata>where
    Balance: Send,

impl<AccountId, Balance, BlockNumber> Send for AuctionInfo<AccountId, Balance, BlockNumber>where
    AccountId: Send,
    Balance: Send,
    BlockNumber: Send,

impl<BlockNumber> Send for OnNewBidResult<BlockNumber>where
    BlockNumber: Send,

impl<CurrencyId, Source> Send for DefaultPriceProvider<CurrencyId, Source>where
    CurrencyId: Send,
    Source: Send,

impl<Value> Send for Change<Value>where
    Value: Send,

impl<Value, Moment> Send for TimestampedValue<Value, Moment>where
    Moment: Send,
    Value: Send,

impl Send for Event

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

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

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

impl<K, V, Hasher> Send for StorageMapIterator<K, V, Hasher>where
    Hasher: Send,
    K: Send,
    V: Send,

impl<K, V, H> Send for StorageMapIteratorShim<K, V, H>where
    H: Send,
    K: Send,
    V: Send,

impl<T> Send for MapIterator<T>

impl<T> Send for MapIteratorShim<T>

impl Send for OffchainErr

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

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

impl<T> Send for Event<T>where
    T: Send,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,

impl<T> Send for GenesisConfig<T>where
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,

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

impl<T> Send for Call<T>where
    T: Send,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,
    <<T as Config>::Lookup as StaticLookup>::Source: Send,

impl<BlockNumber, Balance> Send for VestingSchedule<BlockNumber, Balance>where
    Balance: Send,
    BlockNumber: 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<Alternative, MultiCurrency, CurrencyId, AccountId, Balance> Send for DepositToAlternative<Alternative, MultiCurrency, CurrencyId, AccountId, Balance>where
    AccountId: Send,
    Alternative: Send,
    Balance: Send,
    CurrencyId: Send,
    MultiCurrency: Send,

impl<MultiCurrency, UnknownAsset, Match, AccountId, AccountIdConvert, CurrencyId, CurrencyIdConvert, DepositFailureHandler> Send for MultiCurrencyAdapter<MultiCurrency, UnknownAsset, Match, AccountId, AccountIdConvert, CurrencyId, CurrencyIdConvert, DepositFailureHandler>where
    AccountId: Send,
    AccountIdConvert: Send,
    CurrencyId: Send,
    CurrencyIdConvert: Send,
    DepositFailureHandler: Send,
    Match: Send,
    MultiCurrency: Send,
    UnknownAsset: Send,

impl<CurrencyId, CurrencyIdConvert> Send for IsNativeConcrete<CurrencyId, CurrencyIdConvert>where
    CurrencyId: Send,
    CurrencyIdConvert: Send,

impl<ReserveProvider> Send for MultiNativeAsset<ReserveProvider>where
    ReserveProvider: Send,

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

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

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

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

impl<'a, P> Send for Split<'a, P>where
    <P as Pattern>::__Encoded: Send,

impl Send for RawOsStr

impl Send for RawOsString

impl<O, H> Send for OwningHandle<O, H>where
    H: Send,
    O: Send,

impl<AssetId> Send for AssetType<AssetId>where
    AssetId: Send,

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

impl<T> Send for Event<T>where
    T: Send,
    <T as Config>::StringLimit: Send,

impl<T> Send for Call<T>where
    T: 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 Pallet<T>where
    T: Send,

impl<T> Send for Call<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<T> Send for SealVerify<T>where
    T: Send,

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

impl<I, R, L> Send for EquivocationHandler<I, R, L>where
    I: Send,
    L: Send,
    R: Send,

impl<FullIdentification> Send for BabeEquivocationOffence<FullIdentification>where
    FullIdentification: Send,

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

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

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

impl<T> Send for CurrentBlockRandomness<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,
    <T as Config>::KeyOwnerProof: Send,

impl Send for ListError

impl<T, I> Send for List<T, I>where
    I: Send,
    T: Send,

impl<T, I> Send for Bag<T, I>where
    I: Send,
    <T as Config<I>>::Score: Send,

impl<T, I> Send for Node<T, I>where
    I: Send,
    <T as Config<I>>::Score: Send,

impl<T, I> Send for CheckCounterPrefix<T, I>where
    I: Send,
    T: Send,

impl<T, I> Send for AddScore<T, I>where
    I: Send,
    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,
    <T as Config<I>>::Score: Send,

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

impl<T, I> Send for Call<T, I>where
    I: Send,
    T: Send,
    <<T as Config>::Lookup as StaticLookup>::Source: 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 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<ReserveIdentifier, Balance> Send for ReserveData<ReserveIdentifier, Balance>where
    Balance: Send,
    ReserveIdentifier: Send,

impl<Balance> Send for AccountData<Balance>where
    Balance: Send,

impl<T, I> Send for DustCleaner<T, I>

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

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

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

impl<T, I> Send for Event<T, I>where
    I: Send,
    T: Send,
    <<T as Config<I>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,

impl<T, I> Send for Call<T, I>where
    I: Send,
    T: Send,
    <<T as Config<I>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,
    <<T as Config>::Lookup as StaticLookup>::Source: Send,

impl<AccountId, Balance, BlockNumber> Send for Bounty<AccountId, Balance, BlockNumber>where
    AccountId: Send,
    Balance: Send,
    BlockNumber: Send,

impl<AccountId, BlockNumber> Send for BountyStatus<AccountId, BlockNumber>where
    AccountId: Send,
    BlockNumber: Send,

impl<T> Send for SubstrateWeight<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 Event<T>where
    T: Send,
    <<T as Config<()>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,

impl<T> Send for Call<T>where
    T: Send,
    <<T as Config<()>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,
    <<T as Config>::Lookup as StaticLookup>::Source: Send,

impl<AccountId, Balance, BlockNumber> Send for ChildBounty<AccountId, Balance, BlockNumber>where
    AccountId: Send,
    Balance: Send,
    BlockNumber: Send,

impl<AccountId, BlockNumber> Send for ChildBountyStatus<AccountId, BlockNumber>where
    AccountId: Send,
    BlockNumber: Send,

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

impl<AccountId, Balance> Send for CandidateInfo<AccountId, Balance>where
    AccountId: Send,
    Balance: Send,

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

impl<T> Send for GenesisConfig<T>where
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,

impl<T> Send for Event<T>where
    T: Send,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,

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

impl<T> Send for Call<T>where
    T: Send,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: 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 GenesisConfig<T, I>where
    I: 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 Call<T, I>where
    I: Send,
    T: Send,
    <T as Config<I>>::Proposal: Send,

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

impl<AccountId, BlockNumber> Send for Votes<AccountId, BlockNumber>where
    AccountId: Send,
    BlockNumber: Send,

impl<AccountId, I> Send for EnsureMember<AccountId, I>where
    AccountId: Send,
    I: Send,

impl<AccountId, I, const N: u32> Send for EnsureMembers<AccountId, I, N>where
    AccountId: Send,
    I: Send,

impl<AccountId, I, const N: u32, const D: u32> Send for EnsureProportionMoreThan<AccountId, I, N, D>where
    AccountId: Send,
    I: Send,

impl<AccountId, I, const N: u32, const D: u32> Send for EnsureProportionAtLeast<AccountId, I, N, D>where
    AccountId: Send,
    I: Send,

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

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

impl<T> Send for Event<T>where
    T: Send,
    <<T as Config>::MultiCurrency as MultiCurrencyExtended<<T as Config>::AccountId>>::Amount: Send,
    <<T as Config>::MultiCurrency as MultiCurrency<<T as Config>::AccountId>>::Balance: Send,
    <<T as Config>::MultiCurrency as MultiCurrency<<T as Config>::AccountId>>::CurrencyId: Send,

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

impl<T> Send for Call<T>where
    T: Send,
    <<T as Config>::MultiCurrency as MultiCurrencyExtended<<T as Config>::AccountId>>::Amount: Send,
    <<T as Config>::MultiCurrency as MultiCurrency<<T as Config>::AccountId>>::Balance: Send,
    <<T as Config>::MultiCurrency as MultiCurrency<<T as Config>::AccountId>>::CurrencyId: Send,
    <<T as Config>::Lookup as StaticLookup>::Source: Send,

impl<T, GetCurrencyId> Send for Currency<T, GetCurrencyId>where
    GetCurrencyId: Send,
    T: Send,

impl<T, Currency, Amount, Moment> Send for BasicCurrencyAdapter<T, Currency, Amount, Moment>where
    Amount: Send,
    Currency: Send,
    Moment: Send,
    T: Send,

impl Send for Conviction

impl<Balance> Send for Tally<Balance>where
    Balance: Send,

impl<Balance> Send for Delegations<Balance>where
    Balance: Send,

impl<BlockNumber, Hash, Balance> Send for ReferendumStatus<BlockNumber, Hash, Balance>where
    Balance: Send,
    BlockNumber: Send,
    Hash: Send,

impl<BlockNumber, Hash, Balance> Send for ReferendumInfo<BlockNumber, Hash, Balance>where
    Balance: Send,
    BlockNumber: Send,
    Hash: Send,

impl Send for UnvoteScope

impl Send for Vote

impl<Balance> Send for AccountVote<Balance>where
    Balance: Send,

impl<Balance, AccountId, BlockNumber> Send for Voting<Balance, AccountId, BlockNumber>where
    AccountId: Send,
    Balance: Send,
    BlockNumber: Send,

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

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

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

impl<T> Send for Event<T>where
    T: Send,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,

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

impl<T> Send for Call<T>where
    T: Send,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,
    <<T as Config>::Lookup as StaticLookup>::Source: Send,

impl<AccountId, Balance, BlockNumber> Send for PreimageStatus<AccountId, Balance, BlockNumber>where
    AccountId: Send,
    Balance: Send,
    BlockNumber: Send,

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

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

impl<T> Send for GenesisConfig<T>

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

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

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

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

impl<AccountId, Balance, Solution> Send for SignedSubmission<AccountId, Balance, Solution>where
    AccountId: Send,
    Balance: Send,
    Solution: Send,

impl<T> Send for InsertResult<T>where
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,
    <<T as Config>::MinerConfig as MinerConfig>::Solution: Send,

impl<T> Send for SignedSubmissions<T>where
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,
    <T as Config>::SignedMaxSubmissions: Send,
    <<T as Config>::MinerConfig as MinerConfig>::Solution: Send,

impl Send for MinerError

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

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

impl<T> Send for Event<T>where
    T: Send,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,

impl<T> Send for Error<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>::MinerConfig as MinerConfig>::Solution: Send,

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

impl<Bn> Send for Phase<Bn>where
    Bn: Send,

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

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

impl<T> Send for ElectionError<T>where
    <<T as Config>::Fallback as ElectionProvider>::Error: Send,

impl<T> Send for Pallet<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 Event<T>where
    T: Send,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,

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

impl<T> Send for GenesisConfig<T>where
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,

impl<T> Send for Call<T>where
    T: Send,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,
    <<T as Config>::Lookup as StaticLookup>::Source: Send,

impl Send for Renouncing

impl<AccountId, Balance> Send for Voter<AccountId, Balance>where
    AccountId: Send,
    Balance: Send,

impl<AccountId, Balance> Send for SeatHolder<AccountId, Balance>where
    AccountId: Send,
    Balance: Send,

impl<BlockNumber> Send for OracleEntry<BlockNumber>where
    BlockNumber: Send,

impl<T> Send for BasiliskWeight<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 Event<T>where
    T: Send,

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

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

impl Send for OracleError

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

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

impl<Balance, AccountId> Send for GiltBid<Balance, AccountId>where
    AccountId: Send,
    Balance: Send,

impl<Balance, AccountId, BlockNumber> Send for ActiveGilt<Balance, AccountId, BlockNumber>where
    AccountId: Send,
    Balance: Send,
    BlockNumber: Send,

impl<Balance> Send for ActiveGiltsTotal<Balance>where
    Balance: Send,

impl<T> Send for Event<T>where
    T: Send,
    <T as Config>::CurrencyBalance: Send,

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

impl<Balance> Send for IssuanceInfo<Balance>where
    Balance: Send,

impl<T> Send for Call<T>where
    T: Send,
    <T as Config>::CurrencyBalance: 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<T> Send for Pallet<T>where
    T: Send,

impl Send for Event

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

impl<T> Send for Call<T>where
    T: Send,
    <T as Config>::KeyOwnerProof: Send,

impl<N, Limit> Send for StoredPendingChange<N, Limit>where
    Limit: Send,
    N: Send,

impl<N> Send for StoredState<N>where
    N: Send,

impl Send for Data

impl<Balance> Send for Judgement<Balance>where
    Balance: Send,

impl<FieldLimit> Send for IdentityInfo<FieldLimit>where
    FieldLimit: Send,

impl<Balance, MaxJudgements, MaxAdditionalFields> Send for Registration<Balance, MaxJudgements, MaxAdditionalFields>where
    Balance: Send,
    MaxAdditionalFields: Send,
    MaxJudgements: Send,

impl<Balance, AccountId> Send for RegistrarInfo<Balance, AccountId>where
    AccountId: Send,
    Balance: Send,

impl<T> Send for SubstrateWeight<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 Event<T>where
    T: Send,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,

impl<T> Send for Call<T>where
    T: Send,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,
    <T as Config>::MaxAdditionalFields: Send,
    <<T as Config>::Lookup as StaticLookup>::Source: Send,

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,
    <<T as Config>::ValidatorSet as ValidatorSetWithIdentification<<T as Config>::AccountId>>::Identification: Send,
    <<T as Config>::ValidatorSet as ValidatorSet<<T as Config>::AccountId>>::ValidatorId: Send,

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

impl<T> Send for GenesisConfig<T>

impl<T> Send for Call<T>where
    T: Send,
    <<T as Config>::AuthorityId as RuntimeAppPublic>::Signature: Send,

impl<BlockNumber> Send for Heartbeat<BlockNumber>where
    BlockNumber: Send,

impl<PeerIdEncodingLimit, MultiAddrEncodingLimit, AddressesLimit> Send for BoundedOpaqueNetworkState<PeerIdEncodingLimit, MultiAddrEncodingLimit, AddressesLimit>where
    AddressesLimit: Send,
    MultiAddrEncodingLimit: Send,
    PeerIdEncodingLimit: Send,

impl<Offender> Send for UnresponsivenessOffence<Offender>where
    Offender: Send,

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 GenesisConfig<T>

impl<T> Send for Call<T>where
    T: Send,
    <<T as Config>::Lookup as StaticLookup>::Source: Send,

impl Send for create_pool

impl Send for sell

impl Send for buy

impl<T> Send for HydraWeight<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 Event<T>where
    T: Send,

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

impl<AccountId, BlockNumber> Send for Pool<AccountId, BlockNumber>where
    AccountId: Send,
    BlockNumber: Send,

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

impl<T, I> Send for GlobalFarmData<T, I>

impl<T, I> Send for YieldFarmData<T, I>where
    I: Send,

impl<T, I> Send for DepositData<T, I>where
    I: Send,
    <T as Config<I>>::MaxFarmEntriesPerDeposit: Send,

impl<T, I> Send for YieldFarmEntry<T, I>where
    I: Send,

impl Send for FarmState

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

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

impl<AccountId, Balance, BlockNumber> Send for Offer<AccountId, Balance, BlockNumber>where
    AccountId: Send,
    Balance: Send,
    BlockNumber: Send,

impl<AccountId> Send for Royalty<AccountId>where
    AccountId: Send,

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

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

impl<T> Send for Event<T>where
    T: Send,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,

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

impl<T> Send for Call<T>where
    T: Send,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: 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 GenesisConfig<T, I>where
    I: Send,
    <T as Config<I>>::MaxMembers: Send,

impl<T, I> Send for Event<T, I>where
    I: Send,
    T: Send,
    <T as Config<I>>::Event: Send,

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

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

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

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

impl<BlockHash> Send for LeafProof<BlockHash>where
    BlockHash: Send,

impl<BlockHash> Send for LeafBatchProof<BlockHash>where
    BlockHash: Send,

impl<Client, Block> Send for Mmr<Client, Block>where
    Block: Send,
    Client: Send + Sync,

impl<T> Send for SubstrateWeight<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 Event<T>where
    T: Send,

impl<T> Send for Call<T>where
    T: Send,
    <T as Config>::Call: Send,

impl<BlockNumber> Send for Timepoint<BlockNumber>where
    BlockNumber: Send,

impl<BlockNumber, Balance, AccountId> Send for Multisig<BlockNumber, Balance, AccountId>where
    AccountId: Send,
    Balance: Send,
    BlockNumber: Send,

impl<CollectionType, BoundedVec> Send for CollectionInfo<CollectionType, BoundedVec>where
    BoundedVec: Send,
    CollectionType: Send,

impl<BoundedVec> Send for ItemInfo<BoundedVec>where
    BoundedVec: Send,

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

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

impl<T> Send for Event<T>where
    T: Send,
    <T as Config<()>>::StringLimit: Send,

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

impl<T> Send for Call<T>where
    T: Send,
    <<T as Config>::Lookup as StaticLookup>::Source: Send,
    <T as Config<()>>::StringLimit: Send,

impl<AccountId> Send for OldPoolRoles<AccountId>where
    AccountId: Send,

impl<T> Send for OldBondedPoolInner<T>where
    <T as Config>::CurrencyBalance: Send,

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

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

impl<T> Send for OldPoolMember<T>where
    <T as Config>::CurrencyBalance: Send,
    <T as Config>::MaxUnbonding: Send,

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

impl<T> Send for MigrateToV3<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 GenesisConfig<T>where
    <T as Config>::CurrencyBalance: Send,

impl<T> Send for Event<T>where
    T: Send,
    <T as Config>::CurrencyBalance: Send,

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

impl<T> Send for Call<T>where
    T: Send,
    <T as Config>::CurrencyBalance: Send,
    <<T as Config>::Lookup as StaticLookup>::Source: Send,

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

impl<Balance> Send for BondExtra<Balance>where
    Balance: Send,

impl<T> Send for PoolMember<T>where
    <T as Config>::CurrencyBalance: Send,
    <T as Config>::MaxUnbonding: Send,
    <T as Config>::RewardCounter: Send,

impl Send for PoolState

impl<AccountId> Send for PoolRoles<AccountId>where
    AccountId: Send,

impl<T> Send for BondedPoolInner<T>where
    <T as Config>::CurrencyBalance: Send,

impl<T> Send for BondedPool<T>where
    <T as Config>::CurrencyBalance: Send,

impl<T> Send for RewardPool<T>where
    <T as Config>::CurrencyBalance: Send,
    <T as Config>::RewardCounter: Send,

impl<T> Send for UnbondPool<T>where
    <T as Config>::CurrencyBalance: Send,

impl<T> Send for SubPools<T>where
    T: Send,
    <T as Config>::CurrencyBalance: Send,

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

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

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

impl Send for Event

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

impl<T> Send for Pallet<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 Event<T>where
    T: Send,

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

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

impl<AccountId, Balance> Send for RequestStatus<AccountId, Balance>where
    AccountId: Send,
    Balance: Send,

impl Send for PriceEntry

impl Send for PriceInfo

impl Send for BucketQueue

impl<T> Send for HydraWeight<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 Event<T>where
    T: Send,

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

impl<T> Send for PriceOracleHandler<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 Event<T>where
    T: Send,

impl<T> Send for Error<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, ProxyType, BlockNumber> Send for ProxyDefinition<AccountId, ProxyType, BlockNumber>where
    AccountId: Send,
    BlockNumber: Send,
    ProxyType: Send,

impl<AccountId, Hash, BlockNumber> Send for Announcement<AccountId, Hash, BlockNumber>where
    AccountId: Send,
    BlockNumber: Send,
    Hash: Send,

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,
    <T as Config>::Call: Send,
    <<T as Config>::Lookup as StaticLookup>::Source: Send,

impl<BlockNumber, Balance, Friends> Send for ActiveRecovery<BlockNumber, Balance, Friends>where
    Balance: Send,
    BlockNumber: Send,
    Friends: Send,

impl<BlockNumber, Balance, Friends> Send for RecoveryConfig<BlockNumber, Balance, Friends>where
    Balance: Send,
    BlockNumber: Send,
    Friends: Send,

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

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

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

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

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

impl<T> Send for BasiliskWeight<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<AssetId> Send for Trade<AssetId>where
    AssetId: Send,

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,
    <T as Config>::Call: Send,

impl<Call, BlockNumber, PalletsOrigin, AccountId> Send for ScheduledV3<Call, BlockNumber, PalletsOrigin, AccountId>where
    AccountId: Send,
    BlockNumber: Send,
    Call: Send,
    PalletsOrigin: Send,

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

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

impl<T, I> Send for NoteHistoricalRoot<T, I>where
    I: Send,
    T: Send,

impl<T> Send for ProvingTrie<T>

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

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

impl<T> Send for GenesisConfig<T>

impl Send for Event

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

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

impl<Period, Offset> Send for PeriodicSessions<Period, Offset>where
    Offset: Send,
    Period: Send,

impl<T, Inner> Send for FindAccountFromAuthorIndex<T, Inner>where
    Inner: Send,
    T: Send,

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

impl<T, I> Send for Pallet<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 Event<T, I>where
    I: Send,
    T: Send,
    <<T as Config<I>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,

impl<T, I> Send for GenesisConfig<T, I>where
    <<T as Config<I>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,

impl<T, I> Send for Call<T, I>where
    I: Send,
    T: Send,
    <<T as Config<I>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,
    <<T as Config>::Lookup as StaticLookup>::Source: Send,

impl Send for Vote

impl Send for Judgement

impl<Balance, BlockNumber> Send for Payout<Balance, BlockNumber>where
    Balance: Send,
    BlockNumber: Send,

impl<AccountId, Balance> Send for Bid<AccountId, Balance>where
    AccountId: Send,
    Balance: Send,

impl<AccountId, Balance> Send for BidKind<AccountId, Balance>where
    AccountId: Send,
    Balance: Send,

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

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

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

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

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

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

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

impl<T> Send for GenesisConfig<T>where
    <T as Config>::CurrencyBalance: Send,

impl<T> Send for Event<T>where
    T: Send,
    <T as Config>::CurrencyBalance: Send,

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

impl<T> Send for Call<T>where
    T: Send,
    <T as Config>::CurrencyBalance: Send,
    <<T as Config>::Lookup as StaticLookup>::Source: Send,

impl<AccountId> Send for EraRewardPoints<AccountId>where
    AccountId: Send,

impl<AccountId> Send for StakerStatus<AccountId>where
    AccountId: Send,

impl<AccountId> Send for RewardDestination<AccountId>where
    AccountId: Send,

impl<Balance> Send for UnlockChunk<Balance>where
    Balance: Send,

impl<T> Send for StakingLedger<T>where
    <T as Config>::CurrencyBalance: Send,

impl<T> Send for Nominations<T>where
    <T as Config>::MaxNominations: Send,

impl<AccountId, Balance> Send for IndividualExposure<AccountId, Balance>where
    AccountId: Send,
    Balance: Send,

impl<AccountId, Balance> Send for Exposure<AccountId, Balance>where
    AccountId: Send,
    Balance: Send,

impl<AccountId, Balance> Send for UnappliedSlash<AccountId, Balance>where
    AccountId: Send,
    Balance: Send,

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

impl Send for Forcing

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

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

impl<T, R> Send for FilterHistoricalOffences<T, R>where
    R: Send,
    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 GenesisConfig<T>

impl<T> Send for Call<T>where
    T: Send,
    <T as Config>::Call: Send,
    <<T as Config>::Lookup as StaticLookup>::Source: 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 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,
    <<T as Config<I>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,

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

impl<T, I> Send for Call<T, I>where
    I: Send,
    T: Send,
    <<T as Config<I>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,
    <<T as Config>::Lookup as StaticLookup>::Source: Send,

impl<AccountId, Balance, BlockNumber, Hash> Send for OpenTip<AccountId, Balance, BlockNumber, Hash>where
    AccountId: Send,
    Balance: Send,
    BlockNumber: Send,
    Hash: Send,

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

impl<Balance, AssetId, Price> Send for PaymentInfo<Balance, AssetId, Price>where
    AssetId: Send,
    Balance: Send,
    Price: Send,

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

impl<T> Send for Event<T>where
    T: Send,
    <<T as Config>::Currencies as MultiCurrency<<T as Config>::AccountId>>::Balance: Send,
    <<T as Config>::Currencies as MultiCurrency<<T as Config>::AccountId>>::CurrencyId: Send,

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

impl<T> Send for GenesisConfig<T>where
    <<T as Config>::Currencies as MultiCurrency<<T as Config>::AccountId>>::CurrencyId: Send,

impl<T> Send for Call<T>where
    T: Send,
    <<T as Config>::Currencies as MultiCurrency<<T as Config>::AccountId>>::CurrencyId: Send,

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

impl<MC, DP, DF> Send for TransferFees<MC, DP, DF>where
    DF: Send,
    DP: Send,
    MC: Send,

impl<C, OU, SW> Send for WithdrawFees<C, OU, SW>where
    C: Send,
    OU: Send,
    SW: Send,

impl<T> Send for CurrencyBalanceCheck<T>

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

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

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

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

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

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

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

impl<T> Send for PausedTransactionFilter<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> Send for Pallet<T>where
    T: Send,

impl<T> Send for Event<T>where
    T: Send,
    <<T as Config>::OnChargeTransaction as OnChargeTransaction<T>>::Balance: Send,

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

impl<T, S, V, M> Send for TargetedFeeAdjustment<T, S, V, M>where
    M: Send,
    S: Send,
    T: Send,
    V: 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<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,
    <<T as Config<I>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,

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

impl<T, I> Send for Call<T, I>where
    I: Send,
    T: Send,
    <<T as Config<I>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,
    <<T as Config>::Lookup as StaticLookup>::Source: Send,

impl<AccountId, Balance> Send for Proposal<AccountId, Balance>where
    AccountId: Send,
    Balance: Send,

impl<AccountId, DepositBalance> Send for CollectionDetails<AccountId, DepositBalance>where
    AccountId: Send,
    DepositBalance: Send,

impl<AccountId, DepositBalance> Send for ItemDetails<AccountId, DepositBalance>where
    AccountId: Send,
    DepositBalance: Send,

impl<DepositBalance, StringLimit> Send for CollectionMetadata<DepositBalance, StringLimit>where
    DepositBalance: Send,
    StringLimit: Send,

impl<DepositBalance, StringLimit> Send for ItemMetadata<DepositBalance, StringLimit>where
    DepositBalance: Send,
    StringLimit: 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,
    <<T as Config<I>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,
    <T as Config<I>>::KeyLimit: Send,
    <T as Config<I>>::StringLimit: Send,
    <T as Config<I>>::ValueLimit: Send,

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

impl<T, I> Send for Call<T, I>where
    I: Send,
    T: Send,
    <<T as Config<I>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,
    <T as Config<I>>::KeyLimit: Send,
    <<T as Config>::Lookup as StaticLookup>::Source: Send,
    <T as Config<I>>::StringLimit: Send,
    <T as Config<I>>::ValueLimit: Send,

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

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

impl Send for Event

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

impl<T> Send for Call<T>where
    T: Send,
    <T as Config>::Call: Send,
    <T as Config>::PalletsOrigin: Send,

impl<Balance, BlockNumber> Send for VestingInfo<Balance, BlockNumber>where
    Balance: Send,
    BlockNumber: Send,

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

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

impl<T> Send for GenesisConfig<T>where
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,

impl<T> Send for Event<T>where
    T: Send,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,

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

impl<T> Send for Call<T>where
    T: Send,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,
    <<T as Config>::Lookup as StaticLookup>::Source: Send,

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

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

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

impl Send for Origin

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

impl<BlockNumber> Send for QueryStatus<BlockNumber>where
    BlockNumber: Send,

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

impl<T> Send for Call<T>where
    T: Send,
    <T as Config>::Call: Send,

impl<Prefix, Body> Send for IsMajorityOfBody<Prefix, Body>where
    Body: Send,
    Prefix: Send,

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

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

impl<Origin> Send for XcmPassthrough<Origin>where
    Origin: Send,

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

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

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

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

impl Send for create_pool

impl Send for sell

impl Send for buy

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

impl<T> Send for HydraWeight<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 Event<T>where
    T: Send,

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

impl<T> Send for BasiliskWeight<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 Event<T>where
    T: Send,

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

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

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

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

impl Send for SS58Prefix

impl Send for MaxLocks

impl Send for MaxReserves

impl Send for Ancestry

impl Send for BlockLength

impl Send for BaseRate

impl Send for XcmConfig

impl Send for Event

impl !Send for Origin

impl Send for PalletInfo

impl Send for Call

impl<'a> Send for BTreeIterator<'a>

impl Send for Db

impl<Key, Value> Send for Operation<Key, Value>where
    Key: Send,
    Value: Send,

impl Send for Error

impl Send for Options

impl Send for StatSummary

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

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

impl Send for Error

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 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 Op<R>where
    R: Send,

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

impl<'pratt, 'i, R, F, T> !Send for PrattParserMap<'pratt, 'i, R, F, T>

impl Send for Assoc

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

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

impl<'i> Send for Span<'i>

impl<'i> Send for LinesSpan<'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 Time

impl<N> Send for DfsEvent<N>where
    N: Send,

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

impl<N, VM> Send for Dfs<N, VM>where
    N: Send,
    VM: Send,

impl<N, VM> Send for DfsPostOrder<N, VM>where
    N: Send,
    VM: Send,

impl<N, VM> Send for Bfs<N, VM>where
    N: Send,
    VM: Send,

impl<N, VM> Send for Topo<N, VM>where
    N: Send,
    VM: Send,

impl<W, C> Send for WalkerIter<W, C>where
    C: Send,
    W: Send,

impl<G, F> Send for NodeFiltered<G, F>where
    F: Send,
    G: Send,

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

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

impl<'a, G, I, F> Send for NodeFilteredEdgeReferences<'a, G, I, F>where
    F: Sync,
    G: Send,
    I: Send,

impl<'a, G, I, F> Send for NodeFilteredEdges<'a, G, I, F>where
    F: Sync,
    G: Send,
    I: Send,

impl<G, F> Send for EdgeFiltered<G, F>where
    F: Send,
    G: Send,

impl<'a, G, F> Send for EdgeFilteredNeighbors<'a, G, F>where
    F: Sync,
    <G as IntoEdges>::Edges: Send,

impl<'a, G, I, F> Send for EdgeFilteredEdges<'a, G, I, F>where
    F: Sync,
    G: Send,
    I: Send,

impl<'a, G, F> Send for EdgeFilteredNeighborsDirected<'a, G, F>where
    F: Sync,
    <G as IntoEdgesDirected>::EdgesDirected: Send,
    <G as GraphBase>::NodeId: Send,

impl<G> Send for Reversed<G>where
    G: Send,

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

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

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

impl<N, E> Send for Element<N, E>where
    E: Send,
    N: Send,

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

impl<Ix> Send for EdgeIndex<Ix>where
    Ix: Send,

impl<Ix> Send for OutgoingEdgeIndices<Ix>where
    Ix: Send,

impl<'a, E, Ix> Send for Neighbors<'a, E, Ix>where
    E: Sync,
    Ix: Sync,

impl<'a, E, Ix> Send for EdgeReference<'a, E, Ix>where
    E: Sync,
    Ix: Send + Sync,

impl<'a, E, Ix> Send for EdgeIndices<'a, E, Ix>where
    E: Sync,
    Ix: Sync,

impl<Ix> Send for NodeIndices<Ix>

impl<E, Ix> Send for List<E, Ix>where
    E: Send,
    Ix: Send,

impl<'a, E, Ix> Send for EdgeReferences<'a, E, Ix>where
    E: Sync,
    Ix: Send + Sync,

impl<'a, E, Ix> Send for OutgoingEdgeReferences<'a, E, Ix>where
    E: Sync,
    Ix: Send + Sync,

impl<NodeId, EdgeWeight> Send for Paths<NodeId, EdgeWeight>where
    EdgeWeight: Send,
    NodeId: Send,

impl<N> Send for Dominators<N>where
    N: Send,

impl<'a, N> Send for DominatorsIter<'a, N>where
    N: Send + Sync,

impl<'a, N> Send for DominatedByIter<'a, N>where
    N: Send + Sync,

impl<G> Send for Matching<G>where
    G: Send,
    <G as GraphBase>::NodeId: Send,

impl<'a, G> Send for MatchedNodes<'a, G>where
    G: Sync,
    <G as GraphBase>::NodeId: Sync,

impl<'a, G> Send for MatchedEdges<'a, G>where
    G: Sync,
    <G as GraphBase>::NodeId: Sync,

impl<N, VM> Send for DfsSpace<N, VM>where
    N: Send,
    VM: Send,

impl<N> Send for TarjanScc<N>where
    N: Send,

impl<G> Send for MinSpanningTree<G>where
    G: Send,
    <G as Data>::EdgeWeight: Send,
    <G as GraphBase>::NodeId: Send,
    <G as IntoNodeReferences>::NodeReferences: Send,

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

impl<N, E, Ty, Ix> Send for Csr<N, E, Ty, Ix>where
    E: Send,
    Ix: Send,
    N: Send,
    Ty: Send,

impl<'a, E, Ty, Ix> Send for Edges<'a, E, Ty, Ix>where
    E: Sync,
    Ix: Send + Sync,
    Ty: Send,

impl<'a, E, Ty, Ix> Send for EdgeReference<'a, E, Ty, Ix>where
    E: Sync,
    Ix: Send,
    Ty: Send,

impl<'a, E, Ty, Ix> Send for EdgeReferences<'a, E, Ty, Ix>where
    E: Sync,
    Ix: Send + Sync,
    Ty: Send,

impl<'a, Ix> Send for Neighbors<'a, Ix>where
    Ix: Sync,

impl<Ix> Send for NodeIdentifiers<Ix>where
    Ix: Send,

impl<'a, N, Ix> Send for NodeReferences<'a, N, Ix>where
    Ix: Send,
    N: Sync,

impl<'a, G> !Send for Dot<'a, G>

impl Send for Config

impl<N, E, Ty, Ix> Send for StableGraph<N, E, Ty, Ix>where
    E: Send,
    Ix: Send,
    N: Send,
    Ty: Send,

impl<'a, N, Ix> Send for NodeReferences<'a, N, Ix>where
    Ix: Sync,
    N: Sync,

impl<'a, E, Ix> Send for EdgeReference<'a, E, Ix>where
    E: Sync,
    Ix: Send,

impl<'a, E, Ty, Ix> Send for Edges<'a, E, Ty, Ix>where
    E: Sync,
    Ix: Send + Sync,
    Ty: Send,

impl<'a, E, Ix> Send for EdgeReferences<'a, E, Ix>where
    E: Sync,
    Ix: Sync,

impl<'a, N, Ty, Ix> Send for Externals<'a, N, Ty, Ix>where
    Ix: Sync,
    N: Sync,
    Ty: Send,

impl<'a, E, Ix> Send for Neighbors<'a, E, Ix>where
    E: Sync,
    Ix: Send + Sync,

impl<Ix> Send for WalkNeighbors<Ix>where
    Ix: Send,

impl<'a, N, Ix> Send for NodeIndices<'a, N, Ix>where
    Ix: Sync,
    N: Sync,

impl<'a, E, Ix> Send for EdgeIndices<'a, E, Ix>where
    E: Sync,
    Ix: Sync,

impl<Ix> Send for NodeIndex<Ix>where
    Ix: Send,

impl<Ix> Send for EdgeIndex<Ix>where
    Ix: Send,

impl<N, Ix> Send for Node<N, Ix>where
    Ix: Send,
    N: Send,

impl<E, Ix> Send for Edge<E, Ix>where
    E: Send,
    Ix: Send,

impl<N, E, Ty, Ix> Send for Graph<N, E, Ty, Ix>where
    E: Send,
    Ix: Send,
    N: Send,
    Ty: Send,

impl<'a, N, Ty, Ix> Send for Externals<'a, N, Ty, Ix>where
    Ix: Sync,
    N: Sync,
    Ty: Send,

impl<'a, E, Ix> Send for Neighbors<'a, E, Ix>where
    E: Sync,
    Ix: Send + Sync,

impl<'a, E, Ty, Ix> Send for Edges<'a, E, Ty, Ix>where
    E: Sync,
    Ix: Send + Sync,
    Ty: Send,

impl<'a, E, Ty, Ix> Send for EdgesConnecting<'a, E, Ty, Ix>where
    E: Sync,
    Ix: Send + Sync,
    Ty: Send,

impl<'a, N, Ix> Send for NodeWeightsMut<'a, N, Ix>where
    Ix: Send,
    N: Send,

impl<'a, E, Ix> Send for EdgeWeightsMut<'a, E, Ix>where
    E: Send,
    Ix: Send,

impl<Ix> Send for WalkNeighbors<Ix>where
    Ix: Send,

impl<Ix> Send for NodeIndices<Ix>

impl<Ix> Send for EdgeIndices<Ix>

impl<'a, E, Ix> Send for EdgeReference<'a, E, Ix>where
    E: Sync,
    Ix: Send,

impl<'a, N, Ix> Send for NodeReferences<'a, N, Ix>where
    Ix: Sync,
    N: Sync,

impl<'a, E, Ix> Send for EdgeReferences<'a, E, Ix>where
    E: Sync,
    Ix: Sync,

impl<'a, G> Send for Frozen<'a, G>where
    G: Send,

impl<N, E, Ty> Send for GraphMap<N, E, Ty>where
    E: Send,
    N: Send,
    Ty: Send,

impl<'a, N> Send for Nodes<'a, N>where
    N: Sync,

impl<'a, N, Ty> Send for Neighbors<'a, N, Ty>where
    N: Sync,
    Ty: Send,

impl<'a, N, Ty> Send for NeighborsDirected<'a, N, Ty>where
    N: Send + Sync,
    Ty: Send,

impl<'a, N, E, Ty> Send for Edges<'a, N, E, Ty>where
    E: Sync,
    N: Send + Sync,
    Ty: Send,

impl<'a, N, E, Ty> Send for EdgesDirected<'a, N, E, Ty>where
    E: Sync,
    N: Send + Sync,
    Ty: Send,

impl<'a, N, E, Ty> Send for AllEdges<'a, N, E, Ty>where
    E: Sync,
    N: Sync,
    Ty: Send,

impl<'a, N, E, Ty> Send for AllEdgesMut<'a, N, E, Ty>where
    E: Send,
    N: Send,
    Ty: Send,

impl<'b, T> Send for Ptr<'b, T>where
    T: Sync,

impl<'a, N, E, Ty> Send for NodeIdentifiers<'a, N, E, Ty>where
    E: Send,
    N: Sync,
    Ty: Send,

impl<'a, N, E, Ty> Send for NodeReferences<'a, N, E, Ty>where
    E: Send,
    N: Sync,
    Ty: Send,

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

impl<N, E, Ty, Null, Ix> Send for MatrixGraph<N, E, Ty, Null, Ix>where
    Ix: Send,
    N: Send,
    Null: Send,
    Ty: Send,

impl<'a, Ix> Send for NodeIdentifiers<'a, Ix>where
    Ix: Send,

impl<'a, N, Ix> Send for NodeReferences<'a, N, Ix>where
    Ix: Send,
    N: Sync,

impl<'a, Ty, Null, Ix> Send for EdgeReferences<'a, Ty, Null, Ix>where
    Ix: Send,
    Null: Sync,
    Ty: Send,

impl<'a, Ty, Null, Ix> Send for Neighbors<'a, Ty, Null, Ix>where
    Ix: Send,
    Null: Sync,
    Ty: Send,

impl<'a, Ty, Null, Ix> Send for Edges<'a, Ty, Null, Ix>where
    Ix: Send,
    Null: Sync,
    Ty: Send,

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

impl Send for Direction

impl Send for Directed

impl Send for Undirected

impl Send for Metrics

impl Send for Subcommand

impl Send for RunCmd

impl Send for Cli

impl Send for Client

impl<BlockNumber> Send for InboundDownwardMessage<BlockNumber>where
    BlockNumber: Send,

impl<BlockNumber> Send for InboundHrmpMessage<BlockNumber>where
    BlockNumber: Send,

impl<Id> Send for OutboundHrmpMessage<Id>where
    Id: Send,

impl Send for Metrics

impl<AD> Send for DisputeDistributionSubsystem<AD>where
    AD: Send,

impl Send for Error

impl<'a, I> Send for Branches<'a, I>where
    I: Sync,

impl<AD> Send for GossipSupport<AD>where
    AD: Send,

impl Send for Metrics

impl<N, AD> Send for NetworkBridgeTx<N, AD>where
    AD: Send,
    N: Send,

impl<N, AD> Send for NetworkBridgeRx<N, AD>where
    AD: Send,
    N: Send,

impl Send for Config

impl Send for Metrics

impl Send for Metrics

impl Send for Error

impl Send for Config

impl Send for Error

impl Send for Config

impl<Client> Send for ChainApiSubsystem<Client>where
    Client: Send + Sync,

impl Send for Error

impl Send for Config

impl Send for Config

impl Send for Error

impl Send for Metrics

impl Send for Config

impl Send for Metrics

impl Send for Priority

impl Send for Pvf

impl<Client> Send for RuntimeApiSubsystem<Client>where
    Client: Send + Sync,

impl Send for JaegerError

impl Send for PerLeafSpan

impl Send for Stage

impl Send for Span

impl Send for Jaeger

impl Send for Metronome

impl Send for PeerSet

impl Send for PeerSetIter

impl Send for IsAuthority

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

impl Send for Error

impl Send for FatalError

impl Send for JfyiError

impl<Req> Send for IncomingRequest<Req>where
    Req: Send,

impl<Req> Send for OutgoingResponseSender<Req>where
    Req: Send,

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

impl<Req> Send for IncomingRequestReceiver<Req>where
    Req: Send,

impl Send for Requests

impl<Req> Send for OutgoingRequest<Req>where
    Req: Send,

impl Send for Recipient

impl Send for Protocol

impl Send for OurView

impl Send for View

impl<V1> Send for Versioned<V1>where
    V1: Send,

impl Send for Error

impl Send for Statement

impl Send for PoV

impl<BlockNumber> Send for Collation<BlockNumber>where
    BlockNumber: Send,

impl Send for Proof

impl<M> Send for NetworkBridgeEvent<M>where
    M: Send,

impl Send for LeafStatus

impl Send for Error

impl Send for FatalError

impl Send for JfyiError

impl Send for Config

impl Send for RuntimeInfo

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

impl Send for DbAdapter

impl Send for Error

impl Send for Validator

impl Send for Metrics

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

impl Send for Handle

impl Send for BlockInfo

impl Send for Event

impl<S, SupportsParachains> Send for Overseer<S, SupportsParachains>where
    S: Send,
    SupportsParachains: Send,

impl<T> !Send for Init<T>

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

impl<InitStateSpawner, InitStateSubsystem0, InitStateSubsystem1, InitStateSubsystem2, InitStateSubsystem3, InitStateSubsystem4, InitStateSubsystem5, InitStateSubsystem6, InitStateSubsystem7, InitStateSubsystem8, InitStateSubsystem9, InitStateSubsystem10, InitStateSubsystem11, InitStateSubsystem12, InitStateSubsystem13, InitStateSubsystem14, InitStateSubsystem15, InitStateSubsystem16, InitStateSubsystem17, InitStateSubsystem18, InitStateSubsystem19, InitStateSubsystem20, InitStateSubsystem21, InitStateBaggage0, InitStateBaggage1, InitStateBaggage2, InitStateBaggage3, InitStateBaggage4, InitStateBaggage5, InitStateBaggage6> Send for OverseerBuilder<InitStateSpawner, InitStateSubsystem0, InitStateSubsystem1, InitStateSubsystem2, InitStateSubsystem3, InitStateSubsystem4, InitStateSubsystem5, InitStateSubsystem6, InitStateSubsystem7, InitStateSubsystem8, InitStateSubsystem9, InitStateSubsystem10, InitStateSubsystem11, InitStateSubsystem12, InitStateSubsystem13, InitStateSubsystem14, InitStateSubsystem15, InitStateSubsystem16, InitStateSubsystem17, InitStateSubsystem18, InitStateSubsystem19, InitStateSubsystem20, InitStateSubsystem21, InitStateBaggage0, InitStateBaggage1, InitStateBaggage2, InitStateBaggage3, InitStateBaggage4, InitStateBaggage5, InitStateBaggage6>where
    InitStateBaggage0: Send,
    InitStateBaggage1: Send,
    InitStateBaggage2: Send,
    InitStateBaggage3: Send,
    InitStateBaggage4: Send,
    InitStateBaggage5: Send,
    InitStateBaggage6: Send,
    InitStateSpawner: Send,
    InitStateSubsystem0: Send,
    InitStateSubsystem1: Send,
    InitStateSubsystem10: Send,
    InitStateSubsystem11: Send,
    InitStateSubsystem12: Send,
    InitStateSubsystem13: Send,
    InitStateSubsystem14: Send,
    InitStateSubsystem15: Send,
    InitStateSubsystem16: Send,
    InitStateSubsystem17: Send,
    InitStateSubsystem18: Send,
    InitStateSubsystem19: Send,
    InitStateSubsystem2: Send,
    InitStateSubsystem20: Send,
    InitStateSubsystem21: Send,
    InitStateSubsystem3: Send,
    InitStateSubsystem4: Send,
    InitStateSubsystem5: Send,
    InitStateSubsystem6: Send,
    InitStateSubsystem7: Send,
    InitStateSubsystem8: Send,
    InitStateSubsystem9: Send,

impl<M> Send for OrchestratedSubsystem<M>where
    M: Send,

impl Send for ChannelsOut

impl<OutgoingWrapper> Send for OverseerSender<OutgoingWrapper>where
    OutgoingWrapper: Send,

impl Send for AllMessages

impl Send for HeadData

impl Send for BlockData

impl Send for Id

impl Send for Sibling

impl<Payload, RealPayload> Send for Signed<Payload, RealPayload>where
    Payload: Send,
    RealPayload: Send,

impl<Payload, RealPayload> Send for UncheckedSigned<Payload, RealPayload>where
    Payload: Send,
    RealPayload: Send,

impl<'a> Send for CounterVecDefinition<'a>

impl<H> Send for CandidateDescriptor<H>where
    H: Send,

impl<H> Send for CandidateReceipt<H>where
    H: Send,

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

impl<H> Send for CommittedCandidateReceipt<H>where
    H: Send,

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

impl<N> Send for CandidateCommitments<N>where
    N: Send,

impl<H> Send for BackedCandidate<H>where
    H: Send,

impl Send for CoreIndex

impl Send for GroupIndex

impl<N> Send for GroupRotationInfo<N>where
    N: Send,

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

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

impl<H> Send for CandidateEvent<H>where
    H: Send,

impl<H> Send for ScrapedOnChainVotes<H>where
    H: Send,

impl<N> Send for DisputeState<N>where
    N: Send,

impl<HDR> Send for InherentData<HDR>

impl<H> Send for SigningContext<H>where
    H: Send,

impl Send for SessionInfo

impl Send for BabeDeps

impl<B> Send for GrandpaDeps<B>where
    B: Send + Sync,

impl Send for BeefyDeps

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

impl Send for DotLocation

impl Send for Ancestry

impl Send for Polkadot

impl Send for XcmConfig

impl Send for BaseFilter

impl Send for Version

impl Send for SS58Prefix

impl Send for MaxLocks

impl Send for MaxReserves

impl Send for SessionKeys

impl Send for SignedPhase

impl Send for RewardCurve

impl Send for MaxVotes

impl Send for MaxVoters

impl Send for SpendPeriod

impl Send for Burn

impl Send for MaxKeys

impl Send for MaxRetries

impl Send for Prefix

impl Send for DepositBase

impl Send for MaxProxies

impl Send for MaxPending

impl Send for ProxyType

impl Send for ParaDeposit

impl Send for LeasePeriod

impl Send for LeaseOffset

impl Send for CrowdloanId

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<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<AccountId, LeasePeriod> Send for ParachainTemporarySlot<AccountId, LeasePeriod>where
    AccountId: Send,
    LeasePeriod: Send,

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

impl<T> Send for Event<T>where
    T: Send,
    <<<T as Config>::Leaser as Leaser<<T as Config>::BlockNumber>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,

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

impl<T> Send for Call<T>where
    T: Send,
    <<<T as Config>::Leaser as Leaser<<T as Config>::BlockNumber>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,

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

impl<T> Send for Event<T>where
    T: Send,
    <<<T as Config>::VestingSchedule as VestingSchedule<<T as Config>::AccountId>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,

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

impl<T> Send for GenesisConfig<T>where
    <<<T as Config>::VestingSchedule as VestingSchedule<<T as Config>::AccountId>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,

impl<T> Send for Call<T>where
    T: Send,
    <<<T as Config>::VestingSchedule as VestingSchedule<<T as Config>::AccountId>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,

impl<T> Send for PrevalidateAttests<T>

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

impl<T> Send for Event<T>where
    T: Send,
    <<<T as Config>::Auctioneer as Auctioneer<<T as Config>::BlockNumber>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,

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

impl<T> Send for Call<T>where
    T: Send,
    <<<T as Config>::Auctioneer as Auctioneer<<T as Config>::BlockNumber>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,

impl<BlockNumber> Send for LastContribution<BlockNumber>where
    BlockNumber: Send,

impl<AccountId, Balance, BlockNumber, LeasePeriod> Send for FundInfo<AccountId, Balance, BlockNumber, LeasePeriod>where
    AccountId: Send,
    Balance: Send,
    BlockNumber: Send,
    LeasePeriod: Send,

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

impl<R> Send for DealWithFees<R>where
    R: 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,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,

impl<Account, Balance> Send for ParaInfo<Account, Balance>where
    Account: Send,
    Balance: 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<T> Send for Pallet<T>where
    T: Send,

impl<T> Send for Event<T>where
    T: Send,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,

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

impl<T> Send for Call<T>where
    T: Send,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,

impl<Balance> Send for AccountStatus<Balance>where
    Balance: Send,

impl Send for SlotRange

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

impl<T> Send for Event<T>where
    T: Send,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,

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

impl<T> Send for Call<T>where
    T: Send,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Send,

impl Send for LeaseError

impl<BlockNumber> Send for AuctionStatus<BlockNumber>where
    BlockNumber: Send,

impl<T, W> Send for ChildParachainRouter<T, W>where
    T: Send,
    W: Send,

impl Send for BlockLength

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

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

impl Send for WeightToFee

impl Send for Counter

impl Send for CounterVec

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

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

impl<T> Send for GenesisConfig<T>

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

impl<BlockNumber> Send for HostConfiguration<BlockNumber>where
    BlockNumber: Send,

impl<BlockNumber> Send for InconsistentError<BlockNumber>where
    BlockNumber: Send,

impl<BlockNumber> Send for SessionChangeOutcome<BlockNumber>where
    BlockNumber: 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 Pallet<T>where
    T: Send,

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

impl<BlockNumber> Send for HrmpWatermarkAcceptanceErr<BlockNumber>where
    BlockNumber: 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<N> Send for AvailabilityBitfieldRecord<N>where
    N: Send,

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

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

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

impl<BlockNumber> Send for SessionChangeNotification<BlockNumber>where
    BlockNumber: Send,

impl Send for Metrics

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

impl Send for Origin

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

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

impl Send for Event

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

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

impl<N> Send for ReplacementTimes<N>where
    N: Send,

impl<N> Send for ParaPastCodeMeta<N>where
    N: 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<C> Send for RewardValidatorsWithEraPoints<C>where
    C: Send,

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

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

impl Send for FreedReason

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

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

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

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

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

impl Send for Event

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

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

impl<XcmExecutor, Config> Send for XcmSink<XcmExecutor, Config>where
    Config: Send,
    XcmExecutor: Send,

impl Send for Extensions

impl<B> Send for SelectRelayChain<B>

impl<'a, Spawner, RuntimeClient> Send for OverseerGenArgs<'a, Spawner, RuntimeClient>

impl Send for Error

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

impl Send for IsCollator

impl Send for Error

impl Send for FatalError

impl Send for JfyiError

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

impl<Candidate, Digest> Send for Statement<Candidate, Digest>where
    Candidate: Send,
    Digest: Send,

impl<Candidate, Digest, AuthorityId, Signature> Send for SignedStatement<Candidate, Digest, AuthorityId, Signature>where
    AuthorityId: Send,
    Candidate: Send,
    Digest: Send,
    Signature: Send,

impl<Candidate, Digest, Signature> Send for ValidityDoubleVote<Candidate, Digest, Signature>where
    Candidate: Send,
    Digest: Send,
    Signature: Send,

impl<Candidate, Digest, Signature> Send for DoubleSign<Candidate, Digest, Signature>where
    Candidate: Send,
    Digest: Send,
    Signature: Send,

impl<Candidate, Signature> Send for MultipleCandidates<Candidate, Signature>where
    Candidate: Send,
    Signature: Send,

impl<Candidate, Digest, AuthorityId, Signature> Send for UnauthorizedStatement<Candidate, Digest, AuthorityId, Signature>where
    AuthorityId: Send,
    Candidate: Send,
    Digest: Send,
    Signature: Send,

impl<Candidate, Digest, AuthorityId, Signature> Send for Misbehavior<Candidate, Digest, AuthorityId, Signature>where
    AuthorityId: Send,
    Candidate: Send,
    Digest: Send,
    Signature: Send,

impl<Digest, Group> Send for Summary<Digest, Group>where
    Digest: Send,
    Group: Send,

impl<Signature> Send for ValidityAttestation<Signature>where
    Signature: Send,

impl<Group, Candidate, AuthorityId, Signature> Send for AttestedCandidate<Group, Candidate, AuthorityId, Signature>where
    AuthorityId: Send,
    Candidate: Send,
    Group: Send,
    Signature: Send,

impl<Ctx> Send for CandidateData<Ctx>where
    <Ctx as Context>::AuthorityId: Send,
    <Ctx as Context>::Candidate: Send,
    <Ctx as Context>::GroupId: Send,
    <Ctx as Context>::Signature: Send,

impl<Ctx> Send for Table<Ctx>where
    <Ctx as Context>::AuthorityId: Send,
    <Ctx as Context>::Candidate: Send,
    <Ctx as Context>::Digest: Send,
    <Ctx as Context>::GroupId: Send,
    <Ctx as Context>::Signature: Send,

impl<'a, Ctx> Send for DrainMisbehaviors<'a, Ctx>where
    <Ctx as Context>::AuthorityId: Send,
    <Ctx as Context>::Candidate: Send,
    <Ctx as Context>::Digest: Send,
    <Ctx as Context>::Signature: Send,

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 H384

impl Send for H512

impl Send for H768

impl Send for AssetPair

impl<AccountId, Balance, IntentionID> Send for ExchangeIntention<AccountId, Balance, IntentionID>where
    AccountId: Send,
    Balance: Send,
    IntentionID: Send,

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

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

impl Send for Reason

impl Send for Error

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

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

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

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

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

impl Send for Meter

impl Send for Readout

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

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 Error

impl Send for FoundCrate

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<'a, 'b> !Send for Encoder<'a, 'b>

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

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

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

impl<N, A> Send for Counter<N, A>where
    A: Send + Sync,
    N: Send,

impl<S, V> Send for Exemplar<S, V>where
    S: Send,
    V: Send,

impl<S, N, A> Send for CounterWithExemplar<S, N, A>where
    A: Send + Sync,
    N: Send + Sync,
    S: Send + Sync,

impl<S, N, A> Send for CounterWithExemplarInner<S, N, A>where
    A: Send + Sync,
    N: Send,
    S: Send,

impl<S> Send for HistogramWithExemplars<S>where
    S: Send + Sync,

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

impl<S, M, C> Send for Family<S, M, C>where
    C: Send,
    M: Send + Sync,
    S: Send + Sync,

impl<N, A> Send for Gauge<N, A>where
    A: Send + Sync,
    N: Send,

impl Send for Histogram

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

impl Send for MetricType

impl<M> Send for Registry<M>where
    M: Send,

impl<'a, M> Send for RegistryIterator<'a, M>where
    M: Sync,

impl Send for Descriptor

impl Send for Unit

impl Send for DecodeError

impl Send for EncodeError

impl<In, Out> Send for Codec<In, Out>where
    In: Send,
    Out: Send,

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 SmallRng

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 Frechet<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<F> Send for Gumbel<F>where
    F: Send,

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 SkewNormal<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<F> Send for Zeta<F>where
    F: Send,

impl Send for ZetaError

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

impl Send for ZipfError

impl Send for Lcg128Xsl64

impl Send for Mcg128Xsl64

impl Send for Lcg64Xsh32

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>::Output: 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 Chunks<'data, T>

impl<'data, T> Send for ChunksExact<'data, T>

impl<'data, T> Send for ChunksMut<'data, T>

impl<'data, T> Send for ChunksExactMut<'data, T>

impl<'data, T> Send for RChunks<'data, T>

impl<'data, T> Send for RChunksExact<'data, T>

impl<'data, T> Send for RChunksMut<'data, T>

impl<'data, T> Send for RChunksExactMut<'data, T>

impl<'data, T> Send for Iter<'data, T>

impl<'data, T> Send for Windows<'data, T>

impl<'data, T> Send for IterMut<'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 Send for Error

impl Send for Additive

impl Send for Multiplier

impl Send for AdditiveFFT

impl Send for Additive

impl Send for Multiplier

impl Send for AdditiveFFT

impl Send for CodeParams

impl Send for ReedSolomon

impl Send for IndexSet

impl Send for SetBitsIter

impl Send for Inst

impl Send for Block

impl Send for InstRange

impl<'a, F> Send for Checker<'a, F>where
    F: Sync,

impl Send for RegClass

impl Send for PReg

impl Send for VReg

impl Send for SpillSlot

impl Send for OperandKind

impl Send for OperandPos

impl Send for Operand

impl Send for Allocation

impl Send for ProgPoint

impl Send for Edit

impl<'a> Send for InstOrEdit<'a>

impl<'a> Send for OutputIter<'a>

impl Send for MachineEnv

impl Send for Output

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 RpcService

impl<B> Send for Mode<B>

impl Send for Transport

impl<B> Send for OnlineConfig<B>

impl<B> Send for Builder<B>

impl Send for ParseError

impl Send for Network

impl Send for ScopedIp

impl Send for Config

impl<'a> Send for DomainIter<'a>

impl Send for Lookup

impl Send for Family

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

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 LogLevel

impl !Send for DBPath

impl<F, PF> Send for MergeOperatorCallback<F, PF>

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

impl Send for PerfMetric

impl !Send for PerfContext

impl Send for Error

impl Send for RocLocation

impl Send for Ancestry

impl Send for Rococo

impl Send for XcmConfig

impl Send for SessionKeys

impl Send for Runtime

impl Send for Event

impl !Send for Origin

impl Send for PalletInfo

impl Send for Call

impl Send for BaseFilter

impl Send for Version

impl Send for SS58Prefix

impl Send for SlashPeriod

impl Send for MaxKeys

impl Send for MaxLocks

impl Send for MaxReserves

impl Send for MaxRetries

impl Send for ParaDeposit

impl Send for LeafVersion

impl Send for LeasePeriod

impl Send for CrowdloanId

impl Send for MaxProxies

impl Send for MaxPending

impl Send for ProxyType

impl Send for MaxMembers

impl Send for DepositBase

impl Send for RuntimeApi

impl Send for WeightToFee

impl Send for Handle

impl Send for Error

impl Send for LinkHandle

impl Send for RouteHandle

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

impl Send for IpVersion

impl Send for RuleHandle

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

impl Send for QDiscHandle

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 DirEntry

impl Send for FdFlags

impl Send for Access

impl Send for AtFlags

impl Send for Mode

impl Send for OFlags

impl Send for RenameFlags

impl Send for FileType

impl Send for Advice

impl Send for MemfdFlags

impl Send for SealFlags

impl Send for StatxFlags

impl Send for StatVfs

impl Send for Errno

impl Send for PollFlags

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

impl Send for DupFlags

impl Send for PipeFlags

impl Send for CreateFlags

impl Send for EventFlags

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

impl<'a> Send for Borrowing<'a>

impl<'context, T> Send for Owning<'context, T>where
    T: Sync,

impl<Context> Send for Epoll<Context>where
    Context: Send,

impl<'context, Context> !Send for Iter<'context, Context>

impl<'context, Context> !Send for EventVec<'context, Context>

impl Send for ProtFlags

impl Send for MapFlags

impl Send for MremapFlags

impl Send for MsyncFlags

impl Send for MlockFlags

impl Send for Advice

impl Send for Timestamps

impl Send for OwnedFd

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 ECCurveType

impl Send for Random

impl Send for SessionID

impl Send for ServerName

impl Send for Message

impl<'a> Send for BorrowedPlainMessage<'a>

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

impl Send for Connection

impl Send for IoState

impl<'a> Send for Reader<'a>

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

impl<Data> Send for ConnectionCommon<Data>where
    Data: Send,

impl Send for CommonState

impl Send for Error

impl<'a, C: ?Sized, T: ?Sized> Send for Stream<'a, C, T>where
    C: Send,
    T: Send,

impl<C, T> Send for StreamOwned<C, T>where
    C: Send,
    T: Send,

impl<Side, State> Send for ConfigBuilder<Side, State>where
    Side: Send,
    State: Send,

impl Send for CipherSuite

impl Send for PrivateKey

impl Send for Certificate

impl Send for NoKeyLog

impl Send for KeyLogFile

impl Send for Ticketer

impl Send for ServerName

impl<'a> Send for WriteEarlyData<'a>

impl<'a> Send for ClientHello<'a>

impl<'a> Send for ReadEarlyData<'a>

impl Send for Acceptor

impl Send for Accepted

impl Send for SignError

impl Send for Certificate

impl Send for Item

impl<S> Send for RwStreamSink<S>where
    S: Send,
    <S as TryStream>::Ok: Send,

impl Send for Buffer

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

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

impl Send for Error

impl Send for Service

impl Send for Role

impl<Client, Network, Block, DhtEventStream> Send for Worker<Client, Network, Block, DhtEventStream>where
    Block: Send,
    Client: Send + Sync,
    DhtEventStream: Send,
    Network: Send + Sync,

impl<A, B, C, PR> Send for ProposerFactory<A, B, C, PR>where
    A: Send + Sync,
    B: Send,
    C: Send + Sync,
    PR: Send,

impl<B, Block, C, A, PR> Send for Proposer<B, Block, C, A, PR>where
    B: Send,
    C: Send + Sync,
    PR: Send,

impl Send for RecordProof

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<BlockNumber, T> Send for Forks<BlockNumber, T>where
    BlockNumber: Send,
    T: Send,
    <T as Group>::Fork: Send,

impl Send for ChainType

impl Send for NodeKeyType

impl Send for OutputType

impl Send for RpcMethods

impl Send for Database

impl Send for SyncMode

impl Send for GenerateCmd

impl Send for RevertCmd

impl Send for RunCmd

impl Send for SignCmd

impl Send for VanityCmd

impl Send for VerifyCmd

impl Send for Error

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

impl<Block> Send for ImportSummary<Block>

impl<Block> Send for FinalizeSummary<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<H, N> Send for ImportOutcome<H, N>where
    H: Send,
    N: Send,

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

impl<H, N> Send for FinalizationOutcome<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<Hash> Send for StorageNotification<Hash>where
    Hash: Send,

impl<Block> Send for StorageNotifications<Block>

impl<H> Send for StorageEventStream<H>where
    H: Send,

impl<B> Send for BenchmarkingState<B>

impl<Block> Send for RefTrackingState<Block>

impl<Block> Send for BlockchainDb<Block>

impl<Block> Send for BlockImportOperation<Block>

impl<Block> Send for Backend<Block>

impl Send for ImportedAux

impl<Block> Send for BlockCheckParams<Block>

impl<Block, Transaction> Send for StorageChanges<Block, Transaction>where
    Transaction: Send,

impl<B> Send for ImportedState<B>

impl<Block, Transaction> Send for StateAction<Block, Transaction>where
    Transaction: Send,

impl<Block, Transaction> Send for BlockImportParams<Block, Transaction>where
    Transaction: Send,

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 BlockImportStatus<N>where
    N: Send,

impl<B, Block> Send for LongestChain<B, Block>where
    B: Send + Sync,
    Block: Send,

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

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

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

impl<C, P, CAW, CIDP> Send for AuraVerifier<C, P, CAW, CIDP>where
    C: Send + Sync,
    CAW: Send,
    CIDP: Send,
    P: Send,

impl<'a, Block, I, C, S, CAW, CIDP> Send for ImportQueueParams<'a, Block, I, C, S, CAW, CIDP>where
    C: Send + Sync,
    CAW: Send,
    CIDP: Send,
    I: Send,
    S: Sync,

impl<C, CIDP, CAW> Send for BuildVerifierParams<C, CIDP, CAW>where
    C: Send + Sync,
    CAW: Send,
    CIDP: Send,

impl<C, SC, I, PF, SO, L, CIDP, BS, CAW> Send for StartAuraParams<C, SC, I, PF, SO, L, CIDP, BS, CAW>where
    BS: Send,
    C: Send + Sync,
    CAW: Send,
    CIDP: Send,
    I: Send,
    L: Send,
    PF: Send,
    SC: Send,
    SO: Send,

impl<C, I, PF, SO, L, BS> Send for BuildAuraWorkerParams<C, I, PF, SO, L, BS>where
    BS: Send,
    C: Send + Sync,
    I: Send,
    L: Send,
    PF: Send,
    SO: Send,

impl<B> Send for Error<B>

impl Send for Epoch

impl<B> Send for Error<B>

impl<B> Send for BabeIntermediate<B>

impl<B, C, SC, E, I, SO, L, CIDP, BS, CAW> Send for BabeParams<B, C, SC, E, I, SO, L, CIDP, BS, CAW>where
    BS: Send,
    C: Send + Sync,
    CAW: Send,
    CIDP: Send,
    E: Send,
    I: Send,
    L: Send,
    SC: Send,
    SO: Send,

impl<B> Send for BabeRequest<B>

impl<B> Send for BabeWorkerHandle<B>

impl<B> Send for BabeWorker<B>

impl<Block> Send for BabeLink<Block>

impl<Block, Client, SelectChain, CAW, CIDP> Send for BabeVerifier<Block, Client, SelectChain, CAW, CIDP>where
    CAW: Send,
    CIDP: Send,
    Client: Send + Sync,
    SelectChain: Send,

impl<Block, Client, I> Send for BabeBlockImport<Block, Client, I>where
    Client: Send + Sync,
    I: Send,

impl<B, C, SC> Send for Babe<B, C, SC>where
    C: Send + Sync,
    SC: Send,

impl Send for Error

impl<Hash, Number, E> Send for EpochChangesV0<Hash, Number, E>where
    E: Send,
    Hash: Send,
    Number: Send,

impl<Hash, Number, E> Send for EpochChangesV1<Hash, Number, E>where
    E: Send,
    Hash: Send,
    Number: Send,
    <E as Epoch>::Slot: 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 GapEpochs<Hash, Number, E>where
    E: Send,
    Hash: Send,
    Number: Send,

impl<Hash, Number, E> Send for EpochChanges<Hash, Number, E>where
    E: Send,
    Hash: Send,
    Number: Send,
    <E as Epoch>::Slot: Send,

impl<B> Send for SlotInfo<B>

impl<Block, Proof> Send for SlotResult<Block, Proof>where
    Proof: Send,

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

impl<H, S> Send for CheckedHeader<H, S>where
    H: Send,
    S: Send,

impl<N> Send for BackoffAuthoringOnFinalizedHeadLagging<N>where
    N: Send,

impl<H> Send for WasmExecutor<H>where
    H: Send,

impl Send for Error

impl Send for WasmError

impl Send for Backtrace

impl<Global> Send for GlobalsSnapshot<Global>where
    Global: Send,

impl Send for RuntimeBlob

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

impl !Send for Memory

impl<DT> !Send for Store<DT>

impl<'a> Send for InvokeMethod<'a>

impl Send for Semantics

impl Send for Config

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

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

impl<N> Send for AuthoritySetChanges<N>where
    N: Send,

impl<BE, Block> Send for FinalityProofProvider<BE, Block>where
    BE: Send + Sync,

impl<Header> Send for FinalityProof<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<N> Send for BeforeBestBlockBy<N>where
    N: Send,

impl<Block, B> Send for VotingRulesBuilder<Block, B>

impl Send for Error

impl<Block> Send for WarpSyncFragment<Block>

impl<Block> Send for WarpSyncProof<Block>

impl<Block, Backend> Send for NetworkProvider<Block, Backend>

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> Send for AuthoritySetHardFork<Block>

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<AuthoritySet, VoterState, Block, ProofProvider> Send for Grandpa<AuthoritySet, VoterState, Block, ProofProvider>where
    AuthoritySet: Send,
    ProofProvider: Send + Sync,
    VoterState: Send,

impl Send for Error

impl<B> Send for PeerInfo<B>

impl<B, H> Send for NetworkService<B, H>

impl<'a> Send for NotificationSenderReady<'a>

impl<B, H, Client> Send for NetworkWorker<B, H, Client>

impl<Block> Send for Bitswap<Block>

impl<B, H, Client> Send for Params<B, H, Client>where
    Client: Send + Sync,

impl Send for Role

impl Send for SyncMode

impl Send for SetConfig

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

impl Send for Error

impl Send for Peer

impl Send for Endpoint

impl<B, H> Send for TransactionsHandler<B, H>

impl Send for ProtocolId

impl Send for ParseErr

impl Send for DhtEvent

impl Send for Event

impl Send for Signature

impl<B> Send for NetworkStatus<B>

impl<Header, Hash, Extrinsic> Send for BlockData<Header, Hash, Extrinsic>where
    Extrinsic: Send,
    Hash: Send,
    Header: Send,

impl<Hash, Number> Send for BlockRequest<Hash, Number>where
    Hash: Send,
    Number: Send,

impl<Hash, Number> Send for FromBlock<Hash, Number>where
    Hash: Send,
    Number: Send,

impl<Header, Hash, Extrinsic> Send for BlockResponse<Header, Hash, Extrinsic>where
    Extrinsic: Send,
    Hash: Send,
    Header: Send,

impl<H> Send for BlockAnnounce<H>where
    H: Send,

impl Send for Direction

impl Send for BlockState

impl<H> Send for AnnouncementSummary<H>

impl Send for Metrics

impl<B> Send for WarpProofRequest<B>

impl<Block> Send for VerificationResult<Block>

impl<Block> Send for WarpSyncPhase<Block>

impl<Block> Send for WarpSyncProgress<Block>

impl<Block> Send for PeerInfo<Block>

impl Send for SyncState

impl<Block> Send for SyncStatus<Block>

impl Send for BadPeer

impl<Block> Send for OnBlockData<Block>

impl<Block> Send for OnBlockJustification<Block>

impl<Block> Send for OnStateData<Block>

impl<H> Send for PollBlockAnnounceValidation<H>where
    H: Send,

impl Send for SyncMode

impl Send for Metrics

impl<B> Send for GossipEngine<B>

impl<H> Send for ValidationResult<H>where
    H: Send,

impl Send for DiscardAll

impl<B, Client> Send for LightClientRequestHandler<B, Client>where
    B: Send,
    Client: Send + Sync,

impl<B, Client> Send for BlockRequestHandler<B, Client>where
    Client: Send + Sync,

impl<B> Send for BlockData<B>

impl<B> Send for BlockCollection<B>

impl<B, Client> Send for StateSync<B, Client>where
    Client: Send + Sync,

impl<B> Send for ImportResult<B>

impl<B, Client> Send for StateRequestHandler<B, Client>where
    Client: Send + Sync,

impl<B, Client> Send for WarpSync<B, Client>where
    Client: Send + Sync,

impl<TBlock> Send for RequestHandler<TBlock>

impl<B, Client> Send for ChainSync<B, Client>where
    Client: Send + Sync,

impl<B> Send for PeerSync<B>

impl<B> Send for PeerSyncState<B>

impl<B> Send for AncestorSearchState<B>

impl<Storage> Send for Db<Storage>where
    Storage: Send,

impl<Client, Block> Send for OffchainWorkers<Client, Block>where
    Client: Send + Sync,

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<Block, Client> Send for Dev<Block, Client>where
    Client: Send + Sync,

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

impl Send for Error

impl<Hash> Send for ExtrinsicOrHash<Hash>where
    Hash: Send,

impl Send for Error

impl Send for Error

impl Send for BlockStats

impl Send for Error

impl Send for Error

impl<Hash> Send for ReadProof<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 Send for RpcMetrics

impl Send for WsConfig

impl Send for TaskType

impl Send for RpcMethods

impl Send for BasePath

impl Send for Error

impl<'a, TBl, TCl, TExPool, TRpc, Backend> !Send for SpawnTasksParams<'a, TBl, TCl, TExPool, TRpc, Backend>

impl<'a, TBl, TExPool, TImpQu, TCl> Send for BuildNetworkParams<'a, TBl, TExPool, TImpQu, TCl>where
    TCl: Send + Sync,
    TExPool: Send + Sync,
    TImpQu: Send,

impl<Block, B, E> Send for LocalCallExecutor<Block, B, E>where
    B: Send + Sync,
    E: Send,

impl<Block> Send for ClientConfig<Block>

impl Send for TaskManager

impl Send for RpcHandlers

impl<Client, Backend, SelectChain, ImportQueue, TransactionPool, Other> !Send for PartialComponents<Client, Backend, SelectChain, ImportQueue, TransactionPool, Other>

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, D> Send for StateDbSync<BlockHash, Key, D>where
    D: Send,

impl<BlockHash, Key, D> Send for StateDb<BlockHash, Key, D>where
    D: Send,

impl Send for IsPruned

impl<Block> Send for Error<Block>

impl<Block> Send for LightSyncState<Block>

impl<Block, Client> Send for SyncState<Block, Client>where
    Client: Send + Sync,

impl Send for HwBench

impl Send for Error

impl Send for SysInfo

impl Send for Telemetry

impl Send for Error

impl<Block, Client> Send for BlockExecutor<Block, Client>where
    Client: Send + Sync,

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<Client, Block> Send for FullChainApi<Client, Block>where
    Block: Send,
    Client: Send + Sync,

impl Send for Error

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<Hash, Extrinsic> Send for Transaction<Hash, Extrinsic>where
    Extrinsic: Send,
    Hash: Send,

impl Send for Limit

impl<PoolApi, Block> Send for BasicPool<PoolApi, Block>

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 IDSequence

impl Send for SeqID

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

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

impl<Payload, TK> Send for NotificationStream<Payload, TK>where
    Payload: Send,
    TK: Send,

impl<Payload> Send for NotificationReceiver<Payload>where
    Payload: Send,

impl<Payload> Send for NotificationSender<Payload>where
    Payload: Send,

impl<M, R> Send for Hub<M, R>where
    M: Send,
    R: Send,

impl<M, R> Send for Receiver<M, R>where
    M: Send,
    R: Send,

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

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

impl<F, S> Send for TypeBuilder<F, S>where
    <F as Form>::String: Send,
    <F as Form>::Type: Send,

impl Send for NoFields

impl Send for NamedFields

impl<F> Send for Fields<F>

impl<F, T> Send for FieldsBuilder<F, T>where
    <F as Form>::String: Send,
    <F as Form>::Type: Send,

impl<F, N, T> Send for FieldBuilder<F, N, T>where
    <F as Form>::String: Send,
    <F as Form>::Type: Send,

impl<F> Send for Variants<F>where
    <F as Form>::String: Send,
    <F as Form>::Type: Send,

impl<F, S> Send for VariantBuilder<F, S>where
    S: Send,
    <F as Form>::String: Send,
    <F as Form>::Type: Send,

impl Send for MetaForm

impl<T> Send for UntrackedSymbol<T>

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

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

impl Send for MetaType

impl Send for Registry

impl<T> Send for TypeDefComposite<T>where
    <T as Form>::String: Send,
    <T as Form>::Type: Send,

impl<T> Send for Field<T>where
    <T as Form>::String: Send,
    <T as Form>::Type: Send,

impl<T> Send for Path<T>where
    <T as Form>::String: Send,

impl Send for PathError

impl<T> Send for TypeDefVariant<T>where
    <T as Form>::String: Send,
    <T as Form>::Type: Send,

impl<T> Send for Variant<T>where
    <T as Form>::String: Send,
    <T as Form>::Type: Send,

impl<T> Send for Type<T>where
    <T as Form>::String: Send,
    <T as Form>::Type: Send,

impl<T> Send for TypeParameter<T>where
    <T as Form>::String: Send,
    <T as Form>::Type: Send,

impl<T> Send for TypeDef<T>where
    <T as Form>::String: Send,
    <T as Form>::Type: Send,

impl<T> Send for TypeDefArray<T>where
    <T as Form>::Type: Send,

impl<T> Send for TypeDefTuple<T>where
    <T as Form>::Type: Send,

impl<T> Send for TypeDefSequence<T>where
    <T as Form>::Type: Send,

impl<T> Send for TypeDefCompact<T>where
    <T as Form>::Type: Send,

impl<T> Send for TypeDefBitSequence<T>where
    <T as Form>::Type: Send,

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

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

impl<'a> Send for Log<'a>

impl Send for Error

impl<Size> Send for EncodedPoint<Size>

impl<'a, Size> Send for Coordinates<'a, Size>

impl Send for Tag

impl Send for Error

impl<'a> Send for EcPrivateKey<'a>

impl Send for SignOnly

impl Send for VerifyOnly

impl Send for All

impl<'buf> Send for SignOnlyPreallocated<'buf>

impl<'buf> Send for VerifyOnlyPreallocated<'buf>

impl<'buf> Send for AllPreallocated<'buf>

impl Send for SecretKey

impl Send for PublicKey

impl Send for KeyPair

impl Send for Parity

impl Send for IntoIter

impl Send for RecoveryId

impl Send for Signature

impl Send for Scalar

impl Send for Signature

impl Send for Message

impl Send for Error

impl Send for AlignedType

impl Send for Context

impl Send for PublicKey

impl Send for Signature

impl Send for KeyPair

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<A> Send for EnumAccessDeserializer<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 RawValue

impl Send for Value

impl Send for Sha1

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

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

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

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

impl<'a, T, F> !Send for LinearGroupByKey<'a, T, F>

impl<'a, T, F> !Send for LinearGroupByKeyMut<'a, T, F>

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

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

impl<'a, T, P> !Send for BinaryGroupBy<'a, T, P>

impl<'a, T, P> !Send for BinaryGroupByMut<'a, T, P>

impl<'a, T, F> !Send for BinaryGroupByKey<'a, T, F>

impl<'a, T, F> !Send for BinaryGroupByKeyMut<'a, T, F>

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

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

impl<'a, T, P> !Send for ExponentialGroupBy<'a, T, P>

impl<'a, T, P> !Send for ExponentialGroupByMut<'a, T, P>

impl<'a, T, F> !Send for ExponentialGroupByKey<'a, T, F>

impl<'a, T, F> !Send for ExponentialGroupByKeyMut<'a, T, F>

impl<'a> Send for LinearStrGroup<'a>

impl<'a> Send for LinearStrGroupMut<'a>

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

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

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

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

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

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

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

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

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

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

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

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

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

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

impl<'a, K, V> Send for IterMut<'a, K, V>where
    K: Sync,
    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: Sync,
    V: Send,

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

impl<K, V, S> Send for SparseSecondaryMap<K, V, S>where
    S: Send,
    V: Send,

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

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

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

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

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

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

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

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

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

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

impl Send for KeyData

impl Send for DefaultKey

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

impl Send for Encoder

impl Send for Decoder

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

impl Send for Error

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

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

impl<W> Send for FrameEncoder<W>where
    W: 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<'a> Send for MaybeUninitSlice<'a>

impl Send for OpCode

impl Send for Header

impl Send for Codec

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

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 RequestHeaders<'a>

impl<'a> Send for Response<'a>

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 ApiError

impl<'a, Block, NC, Backend> !Send for CallApiAtParams<'a, Block, 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 FixedI64

impl Send for FixedU64

impl Send for FixedI128

impl Send for FixedU128

impl Send for Rounding

impl Send for Percent

impl Send for PerU16

impl Send for Permill

impl Send for Perbill

impl Send for Perquintill

impl Send for Rational128

impl<H> Send for InherentDataProvider<H>where
    H: Send,

impl<Block> Send for Info<Block>

impl Send for BlockStatus

impl Send for Error

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 Validation

impl Send for Error

impl Send for BlockStatus

impl Send for BlockOrigin

impl<Block, Transaction, Proof> Send for Proposal<Block, Transaction, Proof>where
    Proof: Send,
    Transaction: Send,

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

impl Send for Infallible

impl Send for PublicError

impl Send for AccountId32

impl Send for SecretUri

impl Send for KeyTypeId

impl<'a> Send for HexDisplay<'a>

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

impl Send for Public

impl Send for Signature

impl Send for DeriveError

impl Send for Pair

impl Send for Public

impl Send for Pair

impl Send for Signature

impl Send for DeriveError

impl Send for PoolState

impl Send for StorageKind

impl Send for HttpError

impl Send for Timestamp

impl Send for Duration

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

impl Send for Public

impl Send for Pair

impl Send for Signature

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

impl<H> Send for Change<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 Error

impl<Hash> Send for Proof<Hash>where
    Hash: Send,

impl Send for OpaqueLeaf

impl<H, L> Send for DataOrHash<H, L>where
    L: Send,

impl<H, T> Send for Compact<H, T>where
    H: Send,
    T: Send,

impl<Hash> Send for BatchProof<Hash>where
    Hash: Send,

impl Send for Error

impl<AccountId, P> Send for Assignment<AccountId, P>where
    AccountId: Send,
    P: Send,

impl<AccountId> Send for StakedAssignment<AccountId>where
    AccountId: Send,

impl Send for Error

impl<AccountId> Send for Candidate<AccountId>where
    AccountId: Send,

impl<AccountId> !Send for Edge<AccountId>

impl<AccountId> !Send for Voter<AccountId>

impl<AccountId, P> Send for ElectionResult<AccountId, P>where
    AccountId: Send,
    P: Send,

impl<AccountId> Send for Support<AccountId>where
    AccountId: Send,

impl !Send for AbortGuard

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

impl Send for NumberOrHex

impl Send for BlockTrace

impl Send for Event

impl Send for Span

impl Send for Data

impl Send for TraceError

impl<K, V, S> Send for BoundedBTreeMap<K, V, S>where
    K: Send,
    S: Send,
    V: Send,

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

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

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

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

impl<'a> Send for PiecewiseLinear<'a>

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<AccountId, Call, Extra> Send for CheckedExtrinsic<AccountId, Call, Extra>where
    AccountId: Send,
    Call: Send,
    Extra: Send,

impl Send for Digest

impl Send for DigestItem

impl<'a> Send for DigestItemRef<'a>

impl<'a> Send for OpaqueDigestItemId<'a>

impl Send for Era

impl<Number, Hash> Send for Header<Number, Hash>where
    Number: Send,

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 ModuleError

impl<AccountId, AccountIndex> Send for MultiAddress<AccountId, AccountIndex>where
    AccountId: Send,
    AccountIndex: Send,

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

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 GetDefault

impl<const T: bool> Send for ConstBool<T>

impl<const T: u8> Send for ConstU8<T>

impl<const T: u16> Send for ConstU16<T>

impl<const T: u32> Send for ConstU32<T>

impl<const T: u64> Send for ConstU64<T>

impl<const T: u128> Send for ConstU128<T>

impl<const T: i8> Send for ConstI8<T>

impl<const T: i16> Send for ConstI16<T>

impl<const T: i32> Send for ConstI32<T>

impl<const T: i64> Send for ConstI64<T>

impl<const T: i128> Send for ConstI128<T>

impl<V> Send for Replace<V>where
    V: Send,

impl<N> Send for ReduceBy<N>where
    N: 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 Send for MultiSigner

impl Send for ModuleError

impl<Info> Send for DispatchErrorWithPostInfo<Info>where
    Info: Send,

impl Send for TokenError

impl<R> Send for TransactionOutcome<R>where
    R: 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<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 !Send for Memory

impl<T> !Send for Instance<T>

impl Send for HostError

impl Send for Entry

impl Send for Error

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<'a, H, B> Send for Ext<'a, H, B>where
    B: Sync,

impl<Transaction, H> Send for StorageChanges<Transaction, H>where
    Transaction: Send,

impl<Transaction, H> Send for StorageTransactionCache<Transaction, H>where
    Transaction: Send,

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

impl Send for UsageUnit

impl Send for UsageInfo

impl<H> Send for TestExternalities<H>

impl<S, H, C> Send for TrieBackendBuilder<S, H, C>where
    C: Send,

impl<S, H, C> Send for TrieBackend<S, H, C>where
    C: Send,

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

impl<'a, B, H, Exec> !Send for StateMachine<'a, B, H, 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 Timestamp

impl Send for WasmLevel

impl Send for WasmValue

impl Send for WasmFields

impl<H> Send for SharedTrieCache<H>

impl Send for CacheSize

impl<H> Send for LocalTrieCache<H>

impl<'a, H> !Send for TrieCache<'a, H>

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

impl<H> Send for NodeCodec<H>where
    H: Send,

impl<H> Send for Recorder<H>

impl<H, CodecError> Send for Error<H, CodecError>where
    CodecError: Send,
    H: Send,

impl Send for TrieStream

impl<H> Send for LayoutV0<H>where
    H: Send,

impl<H> Send for LayoutV1<H>where
    H: Send,

impl<'a, DB: ?Sized, H> Send for KeySpacedDB<'a, DB, H>where
    DB: Sync,
    H: Send,

impl<'a, DB: ?Sized, H> Send for KeySpacedDBMut<'a, DB, H>where
    DB: Send,
    H: Send,

impl Send for Error

impl Send for ValueType

impl Send for Value

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

impl Send for Signature

impl<Base, Overlay> Send for ExtendedHostFunctions<Base, Overlay>where
    Base: Send,
    Overlay: Send,

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 ParseError

impl Send for Token

impl Send for TokenAmount

impl<T, F> Send for ConstLazy<T, F>where
    T: Send + Sync,

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

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

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

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 StrSimError

impl Send for ParseError

impl Send for Error

impl Send for Error

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

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

impl Send for Error

impl<C, B, BA> Send for StateMigration<C, B, BA>where
    B: Send,
    BA: Send + Sync,
    C: Send + Sync,

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

impl Send for XcmConfig

impl Send for Alternative

impl Send for SessionKeys

impl Send for BaseFilter

impl Send for Period

impl Send for WeightToFee

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

impl Send for Version

impl Send for ItemDeposit

impl Send for KeyLimit

impl Send for ValueLimit

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 LineEnding

impl<'a> Send for Word<'a>

impl<'a> Send for Options<'a>

impl<'a> Send for SeparatorPolicy<'a>

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

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

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

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

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

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

impl Send for TType

impl<PRC, RTF, IPF, WTF, OPF> Send for TServer<PRC, RTF, IPF, WTF, OPF>where
    IPF: Send,
    OPF: Send,
    RTF: Send,
    WTF: Send,

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

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

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

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

impl Send for TTcpChannel

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

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

impl Send for Error

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<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<'a> Send for ReadBuf<'a>

impl Send for Interest

impl Send for Ready

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

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

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

impl Send for TryIoError

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 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<R> Send for Take<R>where
    R: Send,

impl Send for TcpListener

impl Send for TcpSocket

impl<'a> Send for ReadHalf<'a>

impl<'a> Send for WriteHalf<'a>

impl Send for TcpStream

impl Send for UdpSocket

impl<'a> Send for ReadHalf<'a>

impl<'a> Send for WriteHalf<'a>

impl Send for SocketAddr

impl Send for UnixStream

impl Send for UCred

impl Send for JoinError

impl Send for Builder

impl Send for Handle

impl<'a> Send for EnterGuard<'a>

impl Send for Runtime

impl Send for SignalKind

impl Send for Signal

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

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

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

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

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

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

impl Send for RecvError

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 !Send for LocalSet

impl<T> Send for LocalKey<T>

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

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

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

impl Send for Sleep

impl Send for Error

impl Send for Elapsed

impl Send for Instant

impl Send for Interval

impl<T> Send for Timeout<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 LazyConfigAcceptor<IO>where
    IO: Send,

impl<IO> Send for StartHandshake<IO>where
    IO: Send,

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

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

impl<IO> Send for FallibleConnect<IO>where
    IO: Send,

impl<IO> Send for FallibleAccept<IO>where
    IO: Send,

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

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

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

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

impl Send for Elapsed

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

impl Send for DropGuard

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

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

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

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

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 Date

impl Send for Datetime

impl Send for Offset

impl Send for Time

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 ParseError

impl Send for Directive

impl Send for BadName

impl Send for EnvFilter

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

impl<S, F, R> Send for DynFilterFn<S, F, R>where
    F: Send,
    R: Send,

impl<L, F, S> Send for Filtered<L, F, S>where
    F: Send,
    L: Send,

impl Send for FilterId

impl Send for Targets

impl Send for IntoIter

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

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<'a, L> Send for Scope<'a, L>where
    L: Sync,
    <L as LookupSpan<'a>>::Data: Send,

impl<L, I, S> Send for Layered<L, I, S>where
    I: Send,
    L: Send,

impl Send for Identity

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<H> Send for NodeHandleOwned<H>where
    H: Send,

impl<'a> Send for Value<'a>

impl<H> Send for ValueOwned<H>where
    H: Send,

impl<'a> Send for Node<'a>

impl<H> Send for NodeOwned<H>where
    H: Send,

impl Send for ValuePlan

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<HO> Send for Record<HO>where
    HO: Send,

impl<L> Send for Recorder<L>

impl<'db, 'cache, L> !Send for SecTrieDB<'db, 'cache, L>

impl<'db, L> !Send for SecTrieDBMut<'db, L>

impl<'db, 'cache, L> !Send for TrieDBBuilder<'db, 'cache, L>

impl<'db, 'cache, L> !Send for TrieDB<'db, 'cache, L>

impl<'a, 'cache, L> !Send for TrieDBIterator<'a, 'cache, L>

impl<'a, 'cache, L> !Send for TrieDBKeyIterator<'a, 'cache, L>

impl<L> Send for Value<L>

impl<HO> Send for ChildReference<HO>where
    HO: Send,

impl<'db, L> !Send for TrieDBMutBuilder<'db, L>

impl<'a, L> !Send for TrieDBMut<'a, L>

impl<'db, 'cache, L> !Send for FatDB<'db, 'cache, L>

impl<'db, 'cache, L> !Send for FatDBIterator<'db, 'cache, L>

impl<'db, L> !Send for FatDBMut<'db, L>

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

impl<T> Send for TrieRoot<T>

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

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

impl<'a, 'cache, L> !Send for TrieDBNodeIterator<'a, 'cache, L>

impl<'a, 'cache, L, Q> !Send for Lookup<'a, 'cache, 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<'a, H> Send for TrieAccess<'a, H>where
    H: Send + Sync,

impl Send for TrieSpec

impl Send for TrieFactory

impl<'db, 'cache, L> !Send for TrieKinds<'db, 'cache, L>

impl<H> Send for CachedValue<H>where
    H: Send,

impl Send for Bytes

impl Send for BytesWeak

impl<'a> Send for Value<'a>

impl Send for Unspecified

impl Send for ProtoError

impl Send for Edns

impl Send for Header

impl Send for MessageType

impl Send for Flags

impl Send for Message

impl Send for OpCode

impl Send for Query

impl Send for QueryParts

impl Send for DNSClass

impl Send for Label

impl Send for Name

impl<'a> Send for LabelIter<'a>

impl Send for DEFAULT

impl Send for IP6_ARPA

impl Send for LOCALHOST

impl Send for IP6_ARPA_1

impl Send for LOCAL

impl Send for INVALID

impl Send for ONION

impl Send for UserUsage

impl Send for AppUsage

impl Send for CacheUsage

impl Send for AuthUsage

impl Send for OpUsage

impl Send for ZoneUsage

impl Send for CAA

impl Send for Property

impl Send for Value

impl Send for KeyValue

impl Send for CSYNC

impl Send for HINFO

impl Send for MX

impl Send for NAPTR

impl Send for NULL

impl Send for OPENPGPKEY

impl Send for OPT

impl Send for EdnsCode

impl Send for EdnsOption

impl Send for SOA

impl Send for SRV

impl Send for HEX

impl Send for SSHFP

impl Send for Algorithm

impl Send for SVCB

impl Send for SvcParamKey

impl Send for Mandatory

impl Send for Alpn

impl Send for EchConfig

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

impl Send for Unknown

impl Send for TLSA

impl Send for CertUsage

impl Send for Selector

impl Send for Matching

impl Send for TXT

impl Send for RData

impl Send for RecordType

impl Send for Record

impl Send for RecordParts

impl Send for RecordSet

impl<'r> Send for RrsetRecords<'r>

impl<'a> Send for BinDecoder<'a>

impl Send for DecodeError

impl<'a> Send for BinEncoder<'a>

impl Send for EncodeMode

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

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

impl<S> Send for TcpClientStream<S>

impl<S> Send for TcpClientConnect<S>

impl<S> Send for TcpStream<S>

impl<S, MF> Send for UdpClientStream<S, MF>

impl<S, MF> Send for UdpClientConnect<S, MF>

impl<S> Send for UdpStream<S>

impl Send for DnsExchange

impl<S, TE> Send for DnsExchangeBackground<S, TE>where
    TE: Send,

impl<F, S, TE> Send for DnsExchangeConnect<F, S, TE>where
    TE: Send,

impl<S, MF> Send for DnsMultiplexer<S, MF>

impl<F, S, MF> Send for DnsMultiplexerConnect<F, S, MF>

impl Send for DnsRequest

impl Send for DnsResponse

impl<H> Send for RetryDnsHandle<H>

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

impl<C, P> Send for AsyncResolver<C, P>

impl Send for Protocol

impl Send for Hosts

impl Send for Lookup

impl<'a> Send for LookupIter<'a>

impl<'a> Send for LookupRecordIter<'a>

impl Send for SrvLookup

impl<'i> Send for SrvLookupIter<'i>

impl<'i> Send for ReverseLookupIter<'i>

impl Send for Ipv4Lookup

impl<'i> Send for Ipv4LookupIter<'i>

impl Send for Ipv6Lookup

impl<'i> Send for Ipv6LookupIter<'i>

impl Send for MxLookup

impl<'i> Send for MxLookupIter<'i>

impl Send for TlsaLookup

impl<'i> Send for TlsaLookupIter<'i>

impl Send for TxtLookup

impl<'i> Send for TxtLookupIter<'i>

impl Send for SoaLookup

impl<'i> Send for SoaLookupIter<'i>

impl Send for NsLookup

impl<'i> Send for NsLookupIter<'i>

impl Send for LookupIp

impl<'i> Send for LookupIpIter<'i>

impl<C, E> Send for LookupIpFuture<C, E>

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

impl Send for Command

impl Send for State

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

impl<'text> Send for InitialInfo<'text>

impl<'text> Send for BidiInfo<'text>

impl<'a, 'text> Send for Paragraph<'a, '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<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 Send for Void

impl Send for Giver

impl Send for Taker

impl Send for SharedGiver

impl Send for Closed

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

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

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

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 JsError

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<'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 Encoding

impl Send for Parser

impl<'a> Send for Chunk<'a>

impl<'a> Send for Payload<'a>

impl Send for AliasKind

impl<'a> Send for Alias<'a>

impl<'a> Send for AliasSectionReader<'a>

impl<'a> Send for ComponentExport<'a>

impl<'a> Send for ComponentImport<'a>

impl<'a> Send for ModuleArg<'a>

impl<'a> Send for ComponentArg<'a>

impl<'a> Send for Instance<'a>

impl<'a> Send for InstanceSectionReader<'a>

impl<'a> Send for ComponentTypeDef<'a>

impl<'a> Send for ModuleType<'a>

impl<'a> Send for ComponentType<'a>

impl<'a> Send for InstanceType<'a>

impl<'a> Send for ComponentFuncType<'a>

impl<'a> Send for VariantCase<'a>

impl<'a> Send for InterfaceType<'a>

impl<'a> Send for FunctionBody<'a>

impl<'a> Send for LocalsReader<'a>

impl<'a> Send for LocalsIterator<'a>

impl<'a> Send for CodeSectionReader<'a>

impl<'a> Send for CustomSectionReader<'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<'a> Send for ElementItem<'a>

impl<'a> Send for ElementItemsReader<'a>

impl<'a> Send for ElementItemsIterator<'a>

impl<'a> Send for ElementSectionReader<'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 Send for TypeRef

impl<'a> Send for Import<'a>

impl<'a> Send for ImportSectionReader<'a>

impl<'a> Send for InitExpr<'a>

impl Send for LinkingType

impl<'a> Send for LinkingSectionReader<'a>

impl<'a> Send for MemorySectionReader<'a>

impl<'a> Send for Naming<'a>

impl Send for NameType

impl<'a> Send for SingleName<'a>

impl<'a> Send for NamingReader<'a>

impl<'a> Send for NameMap<'a>

impl<'a> Send for IndirectNaming<'a>

impl<'a> Send for IndirectNamingReader<'a>

impl<'a> Send for IndirectNameMap<'a>

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

impl<'a> Send for NameSectionReader<'a>

impl Send for BlockType

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

impl<'a> Send for SectionCode<'a>

impl Send for Reloc

impl<'a> Send for RelocSectionReader<'a>

impl<'a> Send for TableSectionReader<'a>

impl<'a> Send for TagSectionReader<'a>

impl Send for Type

impl Send for TypeDef

impl Send for FuncType

impl Send for TableType

impl Send for MemoryType

impl Send for GlobalType

impl Send for TagKind

impl Send for TagType

impl<'a> Send for TypeSectionReader<'a>

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

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

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

impl Send for TypeId

impl Send for TypeDef

impl Send for EntityType

impl Send for ModuleType

impl Send for VariantCase

impl Send for RecordType

impl Send for VariantType

impl Send for TupleType

impl Send for UnionType

impl Send for Types

impl Send for Validator

impl<'a> Send for ValidPayload<'a>

impl<Params, Results> Send for TypedFunc<Params, Results>

impl Send for Func

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

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<'instance> Send for Export<'instance>

impl Send for Instance

impl<T> Send for InstancePre<T>

impl Send for StoreLimits

impl<T> Send for Linker<T>

impl Send for Memory

impl Send for FrameInfo

impl Send for FrameSymbol

impl Send for Module

impl Send for ExternRef

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

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

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

impl Send for CallHook

impl Send for Trap

impl Send for TrapCode

impl Send for Mutability

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<'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 FilePos

impl Send for Trampoline

impl Send for Setting

impl Send for SettingKind

impl Send for FlagValue

impl Send for MemoryStyle

impl Send for MemoryPlan

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

impl Send for TableStyle

impl Send for TablePlan

impl Send for ModuleType

impl Send for Module

impl Send for Initializer

impl<'a, 'data> Send for ModuleEnvironment<'a, '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 Send for ModuleTypes

impl Send for StackMap

impl Send for TrapCode

impl Send for Tunables

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

impl Send for HostPtr

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

impl Send for CodeMemory

impl Send for SetupError

impl<'a> Send for SymbolizeContext<'a>

impl Send for VTuneAgent

impl Send for RecordId

impl Send for DebugEntry

impl Send for FileHeader

impl Send for JitDumpFile

impl Send for Export

impl<'a> Send for Imports<'a>

impl !Send for StorePtr

impl Send for LinkError

impl Send for Memory

impl Send for Mmap

impl Send for MmapVec

impl Send for Table

impl !Send for TlsRestore

impl Send for Trap

impl Send for VMContext

impl Send for ValRaw

impl Send for MemoryImage

impl Send for WasmError

impl Send for WasmType

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 TagIndex

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 Tag

impl<'a> Send for EndEntityCert<'a>

impl Send for Error

impl Send for DnsName

impl<'a> Send for DnsNameRef<'a>

impl Send for Time

impl<'a> Send for TrustAnchor<'a>

impl<'a> Send for TlsServerTrustAnchors<'a>

impl<'a> Send for TlsClientTrustAnchors<'a>

impl Send for WndLocation

impl Send for Ancestry

impl Send for Westmint

impl Send for Encointer

impl Send for Collectives

impl Send for XcmConfig

impl Send for BaseFilter

impl Send for Version

impl Send for SS58Prefix

impl Send for MaxLocks

impl Send for MaxReserves

impl Send for Period

impl Send for Offset

impl Send for SessionKeys

impl Send for SignedPhase

impl Send for RewardCurve

impl Send for MaxKeys

impl Send for DepositBase

impl Send for MaxFriends

impl Send for MaxProxies

impl Send for MaxPending

impl Send for ProxyType

impl Send for ParaDeposit

impl Send for LeasePeriod

impl Send for CrowdloanId

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 WeightToFee

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

impl Send for Const

impl Send for Mut

impl<Inner> Send for Frozen<Inner>where
    Inner: Send,

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

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

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

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

impl Send for BodyId

impl Send for BodyPart

impl Send for Junction

impl Send for MultiAsset

impl<Call> Send for Order<Call>where
    Call: Send,

impl Send for Error

impl Send for Outcome

impl Send for OriginKind

impl Send for Response

impl<Call> Send for Xcm<Call>where
    Call: Send,

impl Send for Junction

impl Send for AssetId

impl Send for Fungibility

impl Send for MultiAsset

impl Send for MultiAssets

impl Send for Parent

impl Send for ParentThen

impl Send for Ancestor

impl Send for Junctions

impl<Call> Send for Order<Call>where
    Call: Send,

impl Send for Error

impl Send for Outcome

impl Send for Response

impl<Call> Send for Xcm<Call>where
    Call: Send,

impl Send for Error

impl Send for Outcome

impl Send for SendError

impl<Call> Send for Xcm<Call>where
    Call: Send,

impl Send for Response

impl Send for WeightLimit

impl<Call> Send for Instruction<Call>where
    Call: Send,

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

impl Send for Unsupported

impl<Call> Send for VersionedXcm<Call>where
    Call: Send,

impl Send for AlwaysV0

impl Send for AlwaysV1

impl Send for AlwaysV2

impl<Network, AccountId> Send for Account32Hash<Network, AccountId>where
    AccountId: Send,
    Network: Send,

impl<AccountId> Send for ParentIsPreset<AccountId>where
    AccountId: Send,

impl<ParaId, AccountId> Send for ChildParachainConvertsVia<ParaId, AccountId>where
    AccountId: Send,
    ParaId: Send,

impl<ParaId, AccountId> Send for SiblingParachainConvertsVia<ParaId, AccountId>where
    AccountId: Send,
    ParaId: Send,

impl<Network, AccountId> Send for AccountId32Aliases<Network, AccountId>where
    AccountId: Send,
    Network: Send,

impl<Network, AccountId> Send for AccountKey20Aliases<Network, AccountId>where
    AccountId: Send,
    Network: Send,

impl<Ancestry> Send for LocationInverter<Ancestry>where
    Ancestry: Send,

impl<LocationConverter, Origin> Send for SovereignSignedViaLocation<LocationConverter, Origin>where
    LocationConverter: Send,
    Origin: Send,

impl<Origin> Send for ParentAsSuperuser<Origin>where
    Origin: Send,

impl<ParaId, Origin> Send for ChildSystemParachainAsSuperuser<ParaId, Origin>where
    Origin: Send,
    ParaId: Send,

impl<ParaId, Origin> Send for SiblingSystemParachainAsSuperuser<ParaId, Origin>where
    Origin: Send,
    ParaId: Send,

impl<ParachainOrigin, Origin> Send for ChildParachainAsNative<ParachainOrigin, Origin>where
    Origin: Send,
    ParachainOrigin: Send,

impl<ParachainOrigin, Origin> Send for SiblingParachainAsNative<ParachainOrigin, Origin>where
    Origin: Send,
    ParachainOrigin: Send,

impl<RelayOrigin, Origin> Send for RelayChainAsNative<RelayOrigin, Origin>where
    Origin: Send,
    RelayOrigin: Send,

impl<Network, Origin> Send for SignedAccountId32AsNative<Network, Origin>where
    Network: Send,
    Origin: Send,

impl<Network, Origin> Send for SignedAccountKey20AsNative<Network, Origin>where
    Network: Send,
    Origin: Send,

impl<Origin, Conversion> Send for EnsureXcmOrigin<Origin, Conversion>where
    Conversion: Send,
    Origin: Send,

impl<Origin, AccountId, Network> Send for SignedToAccountId32<Origin, AccountId, Network>where
    AccountId: Send,
    Network: Send,
    Origin: Send,

impl<Origin, COrigin, Body> Send for BackingToPlurality<Origin, COrigin, Body>where
    Body: Send,
    COrigin: Send,
    Origin: Send,

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

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

impl<ParaId> Send for IsChildSystemParachain<ParaId>where
    ParaId: Send,

impl<ResponseHandler> Send for AllowKnownQueryResponses<ResponseHandler>where
    ResponseHandler: Send,

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

impl<Currency, Matcher, AccountIdConverter, AccountId, CheckedAccount> Send for CurrencyAdapter<Currency, Matcher, AccountIdConverter, AccountId, CheckedAccount>where
    AccountId: Send,
    AccountIdConverter: Send,
    CheckedAccount: Send,
    Currency: Send,
    Matcher: Send,

impl<Prefix, AssetId, ConvertAssetId> Send for AsPrefixedGeneralIndex<Prefix, AssetId, ConvertAssetId>where
    AssetId: Send,
    ConvertAssetId: Send,
    Prefix: Send,

impl<AssetId, Balance, ConvertAssetId, ConvertBalance> Send for ConvertedConcreteAssetId<AssetId, Balance, ConvertAssetId, ConvertBalance>where
    AssetId: Send,
    Balance: Send,
    ConvertAssetId: Send,
    ConvertBalance: Send,

impl<AssetId, Balance, ConvertAssetId, ConvertBalance> Send for ConvertedAbstractAssetId<AssetId, Balance, ConvertAssetId, ConvertBalance>where
    AssetId: Send,
    Balance: Send,
    ConvertAssetId: Send,
    ConvertBalance: Send,

impl<Assets, Matcher, AccountIdConverter, AccountId> Send for FungiblesTransferAdapter<Assets, Matcher, AccountIdConverter, AccountId>where
    AccountId: Send,
    AccountIdConverter: Send,
    Assets: Send,
    Matcher: Send,

impl<Assets, Matcher, AccountIdConverter, AccountId, CheckAsset, CheckingAccount> Send for FungiblesMutateAdapter<Assets, Matcher, AccountIdConverter, AccountId, CheckAsset, CheckingAccount>where
    AccountId: Send,
    AccountIdConverter: Send,
    Assets: Send,
    CheckAsset: Send,
    CheckingAccount: Send,
    Matcher: Send,

impl<Assets, Matcher, AccountIdConverter, AccountId, CheckAsset, CheckingAccount> Send for FungiblesAdapter<Assets, Matcher, AccountIdConverter, AccountId, CheckAsset, CheckingAccount>where
    AccountId: Send,
    AccountIdConverter: Send,
    Assets: Send,
    CheckAsset: Send,
    CheckingAccount: Send,
    Matcher: Send,

impl<T, C, M> Send for FixedWeightBounds<T, C, M>where
    C: Send,
    M: Send,
    T: Send,

impl<W, C, M> Send for WeightInfoBounds<W, C, M>where
    C: Send,
    M: Send,
    W: Send,

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

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

impl<WeightToFee, AssetId, AccountId, Currency, OnUnbalanced> Send for UsingComponents<WeightToFee, AssetId, AccountId, Currency, OnUnbalanced>where
    AccountId: Send,
    AssetId: Send,
    Currency: Send,
    OnUnbalanced: Send,
    WeightToFee: Send,
    <Currency as Currency<AccountId>>::Balance: Send,

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

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

impl Send for NativeAsset

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

impl Send for Identity

impl Send for JustTry

impl Send for Encoded

impl Send for Decoded

impl Send for Error

impl Send for Assets

impl<Config> Send for XcmExecutor<Config>where
    Config: Send,
    <Config as Config>::Call: Send,
    <Config as Config>::Trader: Send,

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<'a> Send for Compressor<'a>

impl<'a> Send for Decompressor<'a>

impl<'a> Send for EncoderDictionary<'a>

impl<'a> Send for DecoderDictionary<'a>

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

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

impl<'a, W> Send for Encoder<'a, W>where
    W: Send,

impl<'a, W> Send for Decoder<'a, W>where
    W: Send,

impl<'a, W, F> Send for AutoFinishEncoder<'a, W, F>where
    F: Send,
    W: Send,

impl<'a, W, F> Send for AutoFlushDecoder<'a, W, F>where
    F: Send,
    W: Send,

impl<R, D> Send for Reader<R, D>where
    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<'a> Send for Decoder<'a>

impl<'a> Send for Encoder<'a>

impl<'a> Send for InBuffer<'a>

impl<'a, C: ?Sized> Send for OutBuffer<'a, C>where
    C: Send,

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