Trait scale_info::prelude::marker::Sync

1.0.0 · source ·
pub unsafe auto trait Sync { }
Expand description

Types for which it is safe to share references between threads.

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

The precise definition is: a type T is Sync if and only if &T is Send. In other words, if there is no possibility of undefined behavior (including data races) when passing &T references between threads.

As one would expect, primitive types like u8 and f64 are all Sync, and so are simple aggregate types containing them, like tuples, structs and enums. More examples of basic Sync types include “immutable” types like &T, and those with simple inherited mutability, such as Box<T>, Vec<T> and most other collection types. (Generic parameters need to be Sync for their container to be Sync.)

A somewhat surprising consequence of the definition is that &mut T is Sync (if T is Sync) even though it seems like that might provide unsynchronized mutation. The trick is that a mutable reference behind a shared reference (that is, & &mut T) becomes read-only, as if it were a & &T. Hence there is no risk of a data race.

Types that are not Sync are those that have “interior mutability” in a non-thread-safe form, such as Cell and RefCell. These types allow for mutation of their contents even through an immutable, shared reference. For example the set method on Cell<T> takes &self, so it requires only a shared reference &Cell<T>. The method performs no synchronization, thus Cell cannot be Sync.

Another example of a non-Sync type is the reference-counting pointer Rc. Given any reference &Rc<T>, you can clone a new Rc<T>, modifying the reference counts in a non-atomic way.

For cases when one does need thread-safe interior mutability, Rust provides atomic data types, as well as explicit locking via sync::Mutex and sync::RwLock. These types ensure that any mutation cannot cause data races, hence the types are Sync. Likewise, sync::Arc provides a thread-safe analogue of Rc.

Any types with interior mutability must also use the cell::UnsafeCell wrapper around the value(s) which can be mutated through a shared reference. Failing to doing this is undefined behavior. For example, transmute-ing from &T to &mut T is invalid.

See the Nomicon for more details about Sync.

Implementors§

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

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

Bit-Slice Thread Safety

This allows bit-slice references to be moved across thread boundaries only when the underlying T element can tolerate concurrency.

All BitSlice references, shared or exclusive, are only threadsafe if the T element type is Send, because any given bit-slice reference may only have partial control of a memory element that is also being shared by a bit-slice reference on another thread. As such, this is never implemented for Cell<U>, but always implemented for AtomicU and U for a given unsigned integer type U.

Atomic integers safely handle concurrent writes, cells do not allow concurrency at all, so the only missing piece is &mut BitSlice<_, U: Unsigned>. This is handled by the aliasing system that the mutable splitters employ: a mutable reference to an unsynchronized bit-slice can only cross threads when no other handle is able to exist to the elements it governs. Splitting a mutable bit-slice causes the split halves to change over to either atomics or cells, so concurrency is either safe or impossible.

impl Sync for Executor<'_>

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

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

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

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

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

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

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

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

impl Sync for Condvar

impl Sync for Runnable

impl<T> Sync for Task<T>

impl Sync for AtomicWaker

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

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

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

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

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

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

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

impl Sync for Select<'_>

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

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

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

impl Sync for Collector

impl<T: Send> Sync for ArrayQueue<T>

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

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

impl<T: Sync> Sync for CachePadded<T>

impl Sync for Unparker

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

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

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

impl Sync for Scope<'_>

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

impl Sync for Event

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

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

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

impl<Fut: Sync> Sync for FuturesUnordered<Fut>

impl<T: Send + Sync> Sync for BiLockGuard<'_, T>

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

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

impl<T: ?Sized> Sync for OwnedMutexLockFuture<T>

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

impl<T: ?Sized + Sync> Sync for OwnedMutexGuard<T>

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

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

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

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

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

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

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

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

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

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

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

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

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

impl<K: Sync, V: Sync> Sync for OccupiedEntry<'_, K, V>

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

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

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

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

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

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

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

impl Sync for GuardNoSend

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

impl<'a, R: RawMutex + Sync + 'a, T: ?Sized + Sync + 'a> Sync for MutexGuard<'a, R, T>

impl<'a, R: RawMutex + Sync + 'a, T: ?Sized + Sync + 'a> Sync for MappedMutexGuard<'a, R, T>

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

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

impl<'a, R: RawMutex + Sync + 'a, G: GetThreadId + Sync + 'a, T: ?Sized + Sync + 'a> Sync for ReentrantMutexGuard<'a, R, G, T>

impl<'a, R: RawMutex + Sync + 'a, G: GetThreadId + Sync + 'a, T: ?Sized + Sync + 'a> Sync for MappedReentrantMutexGuard<'a, R, G, T>

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

impl<'a, R: RawRwLockUpgrade + 'a, T: ?Sized + Sync + 'a> Sync for RwLockUpgradableReadGuard<'a, R, T>

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

impl<'a, R: RawRwLock + 'a, T: ?Sized + Sync + 'a> Sync for MappedRwLockWriteGuard<'a, R, T>

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

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

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

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

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

impl<T> Sync for IoVec<T>where
    T: Sync,

impl<T, F: Send> Sync for Lazy<T, F>where
    OnceCell<T>: Sync,

impl<T: Sync + Send> Sync for OnceBox<T>

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

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

impl<T> Sync for SendWrapper<T>

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

impl Sync for LockGuard

impl Sync for Region

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

impl Sync for Options

impl Sync for ReadOptions

impl<'a> Sync for DBPinnableSlice<'a>

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

impl<'a> Sync for SstFileWriter<'a>

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

impl<T, F, S> Sync for ScopeGuard<T, F, S>where
    T: Sync,
    F: FnOnce(T),
    S: Strategy,

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

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

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

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

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

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

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

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

impl<T> Sync for ExchangeableFunction<T>

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

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

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

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

impl<T: Sync> Sync for ConstStatic<T>

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

impl<T: Send> Sync for ThreadLocal<T>

impl<T: Sync> Sync for ReadHalf<T>

impl<T: Sync> Sync for WriteHalf<T>

impl Sync for AbortHandle

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

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

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

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

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

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

impl<'a, T> Sync for MappedMutexGuard<'a, T>where
    T: ?Sized + Sync + 'a,

impl<'a> Sync for Notified<'a>

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

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

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

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

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

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

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

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

impl<T> Sync for Empty<T>

impl<T> Sync for Pending<T>

impl<T> Sync for ReusableBoxFuture<'_, T>

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

impl Sync for ExportTable

impl Sync for VMExternRef

impl Sync for TableElementwhere
    VMExternRef: Sync,

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

impl<'a> Sync for CDict<'a>

impl<'a> Sync for DDict<'a>

Auto implementors§

impl<R> !Sync for Context<R>

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

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

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

impl<R> Sync for FunctionName<R>where
    R: Sync,

impl<'a> Sync for Location<'a>

impl Sync for Adler32

impl Sync for Error

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

impl Sync for Aes128

impl Sync for Aes192

impl Sync for Aes256

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

impl Sync for AHasher

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

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

impl Sync for RandomState

impl<S> Sync for AhoCorasick<S>where
    S: Sync,

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

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

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

impl Sync for MatchKind

impl Sync for Error

impl Sync for ErrorKind

impl Sync for MatchKind

impl Sync for Config

impl Sync for Builder

impl Sync for Searcher

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

impl Sync for Match

impl Sync for Prefix

impl Sync for Infix

impl Sync for Suffix

impl Sync for Style

impl Sync for Colour

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

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

impl Sync for Error

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

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

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

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

impl<'a, S> Sync for CountingSource<'a, S>where
    S: Sync,

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

impl<'a> Sync for SliceSink<'a>

impl<'a> Sync for VecBacking<'a>

impl<'a> Sync for DerObject<'a>

impl<'a> Sync for Boolean<'a>

impl<'a> Sync for Integer<'a>

impl<'a> Sync for Null<'a>

impl<'a> Sync for OctetString<'a>

impl<'a> Sync for Sequence<'a>

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

impl<'a> Sync for Utf8String<'a>

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

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

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

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

impl Sync for RecvError

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

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

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

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

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

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

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

impl Sync for Timer

impl<T> Sync for Async<T>where
    T: Sync,

impl Sync for Barrier

impl Sync for Semaphore

impl<'a> Sync for SemaphoreGuard<'a>

impl Sync for Child

impl Sync for ChildStdin

impl Sync for ChildStdout

impl Sync for ChildStderr

impl Sync for Command

impl Sync for Builder

impl<T> Sync for JoinHandle<T>

impl Sync for Task

impl Sync for TaskId

impl<T> Sync for LocalKey<T>

impl Sync for AccessError

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

impl<S> Sync for Cloned<S>where
    S: Sync,

impl<S> Sync for Copied<S>where
    S: Sync,

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

impl<S> Sync for Fuse<S>where
    S: Sync,

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

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

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

impl<S> Sync for Skip<S>where
    S: Sync,

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

impl<S> Sync for StepBy<S>where
    S: Sync,

impl<S> Sync for Take<S>where
    S: Sync,

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

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

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

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

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

impl<S> Sync for Timeout<S>where
    S: Sync,

impl<T> Sync for Empty<T>where
    T: Sync,

impl<F> Sync for FromFn<F>where
    F: Sync,

impl<I> Sync for FromIter<I>where
    I: Sync,

impl<T> Sync for Once<T>where
    T: Sync,

impl<T> Sync for Repeat<T>where
    T: Sync,

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

impl Sync for Interval

impl<T> Sync for Pending<T>where
    T: Sync,

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

impl<R> Sync for Lines<R>where
    R: Sync,

impl<R> Sync for Split<R>where
    R: Sync,

impl<T> Sync for Bytes<T>where
    T: Sync,

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

impl<T> Sync for Take<T>where
    T: Sync,

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

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

impl<W> Sync for IntoInnerError<W>where
    W: Sync,

impl<T> Sync for Cursor<T>where
    T: Sync,

impl Sync for Empty

impl Sync for Repeat

impl Sync for Sink

impl Sync for Stderr

impl Sync for Stdin

impl Sync for Stdout

impl<'a> Sync for Incoming<'a>

impl Sync for UnixStream

impl Sync for DirBuilder

impl Sync for DirEntry

impl Sync for File

impl Sync for OpenOptions

impl Sync for ReadDir

impl<'a> Sync for Ancestors<'a>

impl<'a> Sync for Components<'a>

impl<'a> Sync for Iter<'a>

impl Sync for Path

impl Sync for PathBuf

impl Sync for TcpListener

impl<'a> Sync for Incoming<'a>

impl Sync for TcpStream

impl Sync for UdpSocket

impl<T> Sync for FallibleTask<T>

impl Sync for BytesCodec

impl Sync for LengthCodec

impl Sync for LinesCodec

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

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

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

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

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

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

impl Sync for Stream

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

impl Sync for Zero

impl Sync for Stop

impl Sync for Constant

impl Sync for SystemClock

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

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

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

impl<S, B, N, Fn, Fut> Sync for Retry<S, B, N, Fn, Fut>where
    B: Sync,
    Fn: Sync,
    Fut: Sync,
    N: Sync,
    S: Sync,
    <S as Sleeper>::Sleep: Sync,

impl Sync for Frame

impl !Sync for Symbol

impl<'a> Sync for SymbolName<'a>

impl<'a> Sync for BytesOrWideString<'a>

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

impl Sync for PrintFmt

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

impl Sync for Backtrace

impl<'a> Sync for HexDisplay<'a>

impl Sync for Error

impl<'a> Sync for Base64Display<'a>

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

impl<W> Sync for EncoderWriter<W>where
    W: Sync,

impl<S> Sync for EncoderStringWriter<S>where
    S: Sync,

impl Sync for DecodeError

impl Sync for Config

impl Sync for DecodeError

impl Sync for Extensions

impl Sync for Client

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

impl<C> !Sync for NewFull<C>

impl Sync for Ancestry

impl Sync for XcmConfig

impl Sync for Alternative

impl Sync for Benchmark

impl Sync for Benchmark

impl Sync for buy

impl Sync for set_price

impl Sync for make_offer

impl Sync for add_royalty

impl Sync for Benchmark

impl Sync for Benchmark

impl Sync for sell

impl Sync for buy

impl Sync for Benchmark

impl Sync for transfer

impl Sync for set_balance

impl Sync for Benchmark

impl Sync for claim

impl Sync for Benchmark

impl Sync for SessionKeys

impl Sync for BaseFilter

impl Sync for WeightToFee

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

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

impl Sync for Version

impl Sync for ItemDeposit

impl Sync for KeyLimit

impl Sync for ValueLimit

impl Sync for Runtime

impl Sync for Event

impl !Sync for Origin

impl Sync for PalletInfo

impl Sync for Call

impl Sync for RuntimeApi

impl<Block, Backend, RuntimeApi, I> Sync for BeefyBlockImport<Block, Backend, RuntimeApi, I>where
    Backend: Send + Sync,
    I: Sync,
    RuntimeApi: Send + Sync,

impl<B> Sync for BeefyVoterLinks<B>

impl<B> Sync for BeefyRPCLinks<B>

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

impl Sync for Error

impl Sync for ErrorCode

impl<Block> Sync for Beefy<Block>

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

impl<'a> Sync for Leaf<'a>

impl Sync for Payload

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

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

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

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

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

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

impl Sync for Public

impl Sync for Signature

impl Sync for Pair

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

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

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

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

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

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

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

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

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

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

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

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

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

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

impl Sync for BigEndian

impl Sync for Config

impl Sync for Bounded

impl Sync for Infinite

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

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

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

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

impl<'storage> Sync for SliceReader<'storage>

impl<R> Sync for IoReader<R>where
    R: Sync,

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

impl Sync for ErrorKind

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

impl Sync for ErrorKind

impl Sync for Language

impl Sync for Mnemonic

impl Sync for Seed

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

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

impl Sync for Blake2b

impl Sync for Blake2s

impl Sync for Params

impl Sync for State

impl<'a> Sync for HashManyJob<'a>

impl Sync for Params

impl Sync for State

impl Sync for Hash

impl Sync for Params

impl Sync for State

impl<'a> Sync for HashManyJob<'a>

impl Sync for Params

impl Sync for State

impl Sync for Hash

impl Sync for Hash

impl Sync for HexError

impl Sync for Hasher

impl Sync for Eager

impl Sync for Lazy

impl Sync for Error

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

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

impl<T, const L: usize, const U: usize> Sync for BoundedVec<T, L, U>where
    T: Sync,

impl Sync for Alphabet

impl Sync for Error

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

impl Sync for Error

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

impl Sync for Error

impl Sync for BStr

impl Sync for BString

impl<'a> Sync for Finder<'a>

impl<'a> Sync for FinderReverse<'a>

impl<'a> Sync for Find<'a>

impl<'a> Sync for FindReverse<'a>

impl<'a> Sync for Bytes<'a>

impl<'a> Sync for Fields<'a>

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

impl<'a> Sync for Split<'a>

impl<'a> Sync for SplitReverse<'a>

impl<'a> Sync for SplitN<'a>

impl<'a> Sync for SplitNReverse<'a>

impl<'a> Sync for Lines<'a>

impl<'a> Sync for LinesWithTerminator<'a>

impl<'a> Sync for DrainBytes<'a>

impl<B> Sync for ByteLines<B>where
    B: Sync,

impl<B> Sync for ByteRecords<B>where
    B: Sync,

impl<'a> Sync for Chars<'a>

impl<'a> Sync for CharIndices<'a>

impl<'a> Sync for Utf8Chunks<'a>

impl<'a> Sync for Utf8Chunk<'a>

impl Sync for Utf8Error

impl Sync for AllocErr

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

impl !Sync for Bump

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

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

impl Sync for Error

impl Sync for BigEndian

impl !Sync for bz_stream

impl Sync for ParseError

impl Sync for Reason

impl<'a> Sync for Token<'a>

impl<'a> Sync for Lexer<'a>

impl<'a> Sync for LexerToken<'a>

impl Sync for Func

impl<'a> Sync for Predicate<'a>

impl Sync for Expression

impl Sync for Triple

impl Sync for Arch

impl Sync for Vendor

impl Sync for Os

impl Sync for Family

impl Sync for Env

impl Sync for Panic

impl Sync for HasAtomic

impl Sync for Families

impl Sync for HasAtomics

impl Sync for Endian

impl Sync for TargetInfo

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

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

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

impl<Tz> Sync for Date<Tz>where
    <Tz as TimeZone>::Offset: Sync,

impl<Tz> Sync for DateTime<Tz>where
    <Tz as TimeZone>::Offset: Sync,

impl Sync for Parsed

impl<'a> Sync for StrftimeItems<'a>

impl Sync for Pad

impl Sync for Numeric

impl Sync for Fixed

impl<'a> Sync for Item<'a>

impl Sync for ParseError

impl<I> Sync for DelayedFormat<I>where
    I: Sync,

impl Sync for NaiveWeek

impl Sync for NaiveDate

impl Sync for IsoWeek

impl Sync for NaiveTime

impl Sync for FixedOffset

impl Sync for Local

impl Sync for Utc

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

impl Sync for Weekday

impl Sync for Month

impl Sync for Months

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

impl Sync for Error

impl Sync for Version

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

impl Sync for Error

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

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

impl<T> !Sync for MemStore<T>

impl<T, M> !Sync for MemMMR<T, M>

impl Sync for ArgAction

impl Sync for AppSettings

impl<'help> Sync for Arg<'help>

impl<'help> Sync for ArgGroup<'help>

impl Sync for ArgSettings

impl<'help> Sync for App<'help>

impl<'help> Sync for PossibleValue<'help>

impl Sync for ValueHint

impl Sync for ValueParser

impl<E> Sync for EnumValueParser<E>

impl<T> Sync for RangedI64ValueParser<T>

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

impl Sync for ContextKind

impl Sync for ErrorKind

impl Sync for Error

impl Sync for ArgMatches

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

impl<'a> Sync for RawValues<'a>

impl<'a> Sync for Values<'a>

impl<'a> Sync for OsValues<'a>

impl<'a> Sync for Indices<'a>

impl Sync for ValueSource

impl Sync for ColorChoice

impl Sync for RawArgs

impl Sync for ArgCursor

impl<'s> Sync for ParsedArg<'s>

impl<'s> Sync for ShortFlags<'s>

impl Sync for Clock

impl Sync for Duration

impl Sync for Instant

impl Sync for Updater

impl Sync for Cell

impl Sync for Cells

impl Sync for Column

impl Sync for Row

impl Sync for Width

impl Sync for Table

impl<'a> Sync for ColumnCellIter<'a>

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

impl Sync for BlockLength

impl Sync for SS58Prefix

impl Sync for MaxLocks

impl Sync for MaxReserves

impl Sync for ProxyType

impl Sync for MaxProxies

impl Sync for MaxPending

impl Sync for ExchangeFee

impl Sync for MaxInRatio

impl Sync for MaxOutRatio

impl Sync for MaxVotes

impl Sync for SpendPeriod

impl Sync for Burn

impl Sync for PotId

impl Sync for Period

impl Sync for Offset

impl Sync for LMPalletId

impl Sync for DepositBase

impl Sync for PopError

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

impl<'a> Sync for Arcs<'a>

impl Sync for Error

impl Sync for Case

impl Sync for FromCasing

impl<T> Sync for Cursor<T>where
    T: Sync,

impl Sync for Error

impl Sync for ErrorKind

impl Sync for SeekFrom

impl<R> Sync for Bytes<R>where
    R: Sync,

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

impl<T> Sync for Take<T>where
    T: Sync,

impl !Sync for ParseContext

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

impl Sync for MangledName

impl Sync for Encoding

impl Sync for CloneSuffix

impl Sync for Name

impl Sync for NestedName

impl Sync for Prefix

impl Sync for SourceName

impl Sync for TaggedName

impl Sync for Identifier

impl Sync for SeqId

impl Sync for CallOffset

impl Sync for NvOffset

impl Sync for VOffset

impl Sync for Type

impl Sync for TypeHandle

impl Sync for BuiltinType

impl Sync for Decltype

impl Sync for ArrayType

impl Sync for VectorType

impl Sync for TemplateArg

impl Sync for MemberName

impl Sync for Expression

impl Sync for SimpleId

impl Sync for ExprPrimary

impl Sync for Initializer

impl Sync for LocalName

impl Sync for LambdaSig

impl Sync for SpecialName

impl Sync for Error

impl<T> Sync for Symbol<T>where
    T: Sync,

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

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

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

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

impl<K> Sync for SetForest<K>where
    K: Sync,

impl<K> Sync for Set<K>where
    K: Sync,

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

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

impl Sync for MachReloc

impl Sync for MachTrap

impl Sync for MachSrcLoc

impl Sync for StackMap

impl Sync for Reloc

impl Sync for CodeInfo

impl<'a> Sync for CFGPrinter<'a>

impl<'f> Sync for FuncCursor<'f>

impl Sync for DataValue

impl<'a> Sync for DisplayDataValues<'a>

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

impl<'a> Sync for ChildIter<'a>

impl<'a> Sync for PredIter<'a>

impl Sync for AtomicRmwOp

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

impl<'f> Sync for ReplaceBuilder<'f>

impl Sync for IntCC

impl Sync for FloatCC

impl<'a> Sync for Values<'a>

impl Sync for ValueDef

impl<'a> Sync for DisplayInst<'a>

impl Sync for Block

impl Sync for Value

impl Sync for Inst

impl Sync for StackSlot

impl Sync for GlobalValue

impl Sync for Constant

impl Sync for Immediate

impl Sync for JumpTable

impl Sync for FuncRef

impl Sync for SigRef

impl Sync for Heap

impl Sync for Table

impl Sync for AnyEntity

impl Sync for Signature

impl Sync for AbiParam

impl Sync for ExtFuncData

impl Sync for Function

impl<'a> Sync for DisplayFunction<'a>

impl Sync for HeapData

impl Sync for HeapStyle

impl Sync for Imm64

impl Sync for Uimm64

impl Sync for Uimm32

impl Sync for V128Imm

impl Sync for Offset32

impl Sync for Ieee32

impl Sync for Ieee64

impl Sync for Opcode

impl<'a> Sync for BranchInfo<'a>

impl<'a> Sync for CallInfo<'a>

impl Sync for Layout

impl<'f> Sync for Blocks<'f>

impl<'f> Sync for Insts<'f>

impl Sync for LibCall

impl Sync for Endianness

impl Sync for MemFlags

impl Sync for SourceLoc

impl Sync for TableData

impl Sync for TrapCode

impl Sync for Type

impl Sync for ValueLabel

impl Sync for Register

impl Sync for EvexContext

impl Sync for EvexMasking

impl Sync for OpcodeMap

impl Sync for UnwindInfo

impl Sync for UnwindInfo

impl Sync for UnwindInfo

impl Sync for UnwindInst

impl Sync for CallConv

impl Sync for LookupError

impl Sync for Builder

impl Sync for Loop

impl Sync for Template

impl Sync for Descriptor

impl Sync for Detail

impl Sync for SettingKind

impl Sync for Setting

impl Sync for Value

impl Sync for Builder

impl Sync for SetError

impl<'a> Sync for PredicateView<'a>

impl Sync for Flags

impl Sync for OptLevel

impl Sync for TlsModel

impl<'a> Sync for FlagsOrIsa<'a>

impl Sync for TimingToken

impl Sync for PassTimes

impl Sync for PlainWriter

impl Sync for Context

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

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

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

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

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

impl<T> Sync for EntityList<T>where
    T: Sync,

impl<T> Sync for ListPool<T>where
    T: Sync,

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

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

impl<K> Sync for EntitySet<K>where
    K: Sync,

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

impl<'a> Sync for FunctionBuilder<'a>

impl Sync for Switch

impl Sync for Variable

impl Sync for ReturnMode

impl Sync for Hasher

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

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

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

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

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

impl<T> Sync for SendTimeoutError<T>where
    T: Sync,

impl Sync for RecvError

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

impl<T> !Sync for Worker<T>

impl<T> Sync for Steal<T>where
    T: Sync,

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

impl<T: ?Sized> Sync for Owned<T>where
    T: Sync,

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

impl !Sync for LocalHandle

impl !Sync for Guard

impl !Sync for Backoff

impl !Sync for Parker

impl Sync for WaitGroup

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

impl<T> Sync for Checked<T>where
    T: Sync,

impl Sync for Limb

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

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

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

impl Sync for MacError

impl<M> Sync for Output<M>

impl Sync for Ctr128BE

impl Sync for Ctr128LE

impl Sync for Ctr32BE

impl Sync for Ctr32LE

impl Sync for Ctr64BE

impl Sync for Ctr64LE

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

impl Sync for CuckooError

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

impl Sync for RunCmd

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

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

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

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

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

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

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

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

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

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

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

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

impl<Block> Sync for WaitToAnnounce<Block>

impl<Block, PC, IQ, RC> !Sync for PoVRecovery<Block, PC, IQ, RC>

impl<'a, Block, BS, Client, RCInterface, Spawner, IQ> !Sync for StartCollatorParams<'a, Block, BS, Client, RCInterface, Spawner, IQ>

impl<'a, Block, Client, RCInterface, IQ> !Sync for StartFullNodeParams<'a, Block, Client, RCInterface, IQ>

impl<Block> Sync for SharedImportQueue<Block>

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

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

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

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

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

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

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

impl Sync for ConfigData

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

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

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

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

impl<T> Sync for ParachainSetCode<T>where
    T: Sync,

impl<T> Sync for RelaychainBlockNumberProvider<T>where
    T: Sync,

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

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

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

impl Sync for Origin

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

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

impl<T> Sync for LimitAndDropDmpExecution<T>where
    T: Sync,

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

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

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

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

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

impl Sync for ChannelInfo

impl<B> Sync for ParachainBlockData<B>

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

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

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

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

impl Sync for Scalar

impl Sync for DecodeKind

impl Sync for DecodeError

impl Sync for BitOrder

impl Sync for Encoding

impl Sync for Translate

impl Sync for Wrap

impl<'a> Sync for Any<'a>

impl<'a> Sync for BitString<'a>

impl<'a> Sync for BitStringIter<'a>

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

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

impl<'a> Sync for Ia5String<'a>

impl<'a> Sync for UIntBytes<'a>

impl Sync for Null

impl<'a> Sync for OctetString<'a>

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

impl<'a> Sync for PrintableString<'a>

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

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

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

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

impl Sync for UtcTime

impl<'a> Sync for Utf8String<'a>

impl Sync for DateTime

impl<'a> Sync for Decoder<'a>

impl<'a> Sync for Encoder<'a>

impl Sync for Error

impl Sync for ErrorKind

impl Sync for Header

impl Sync for Length

impl Sync for Class

impl Sync for TagMode

impl Sync for TagNumber

impl Sync for Tag

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

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

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

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

impl Sync for TruncSide

impl<T> Sync for CtOutput<T>

impl Sync for MacError

impl Sync for BaseDirs

impl Sync for UserDirs

impl Sync for ProjectDirs

impl Sync for BaseDirs

impl Sync for UserDirs

impl Sync for ProjectDirs

impl Sync for Type

impl Sync for QueryType

impl Sync for Class

impl Sync for QueryClass

impl Sync for Opcode

impl<'a> Sync for Packet<'a>

impl<'a> Sync for Question<'a>

impl<'a> Sync for ResourceRecord<'a>

impl<'a> Sync for Name<'a>

impl Sync for Error

impl Sync for Header

impl Sync for Builder

impl Sync for Record

impl Sync for Record

impl Sync for Record

impl Sync for Record

impl<'a> Sync for Record<'a>

impl Sync for Record

impl Sync for Record

impl Sync for Record

impl Sync for Record

impl Sync for Record

impl Sync for Record

impl Sync for Record

impl Sync for Record

impl<'a> Sync for Record<'a>

impl<'a> Sync for Record<'a>

impl Sync for Record

impl Sync for Record

impl<'a> Sync for Record<'a>

impl<'a> Sync for Record<'a>

impl<'a> Sync for Record<'a>

impl<'a> Sync for Record<'a>

impl<'a> Sync for Record<'a>

impl<'a> Sync for RecordIter<'a>

impl Sync for Record

impl<'a> Sync for RData<'a>

impl Sync for Buffer

impl Sync for RecoveryId

impl<C> Sync for Signature<C>

impl<C> Sync for SigningKey<C>

impl<C> Sync for VerifyingKey<C>

impl<C> Sync for Signature<C>

impl Sync for Signature

impl Sync for Keypair

impl Sync for PublicKey

impl Sync for SecretKey

impl Sync for Item

impl Sync for Verifier

impl Sync for Error

impl Sync for Signature

impl Sync for SigningKey

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

impl Sync for Error

impl<C> Sync for ScalarCore<C>

impl<C> Sync for NonZeroScalar<C>

impl<C> Sync for SecretKey<C>

impl<C> Sync for PublicKey<C>

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

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

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

impl<T> Sync for Iter<T>where
    T: Sync,
    <T as RawBitFlags>::Numeric: Sync,

impl Sync for Filter

impl Sync for Builder

impl Sync for Timestamp

impl !Sync for Style

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

impl Sync for Color

impl !Sync for Target

impl Sync for WriteStyle

impl !Sync for Formatter

impl<'a> Sync for Env<'a>

impl Sync for Logger

impl Sync for Builder

impl Sync for Errno

impl Sync for Exit

impl Sync for Signal

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

impl !Sync for Rng

impl Sync for Phase

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

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

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

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

impl<Id> Sync for RoundState<Id>where
    Id: Sync,

impl<Id> Sync for VoterState<Id>where
    Id: Sync,

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

impl Sync for GoodCommit

impl Sync for BadCommit

impl Sync for GoodCatchUp

impl Sync for BadCatchUp

impl<O> !Sync for Callback<O>

impl<H, N, S, Id> !Sync for CommunicationIn<H, N, S, Id>

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

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

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

impl Sync for VoterInfo

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

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

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

impl Sync for Error

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

impl Sync for F128Bits

impl Sync for FixedBitSet

impl<'a> Sync for Difference<'a>

impl<'a> Sync for SymmetricDifference<'a>

impl<'a> Sync for Intersection<'a>

impl<'a> Sync for Union<'a>

impl<'a> Sync for Ones<'a>

impl Sync for Crc

impl<R> Sync for CrcReader<R>where
    R: Sync,

impl<W> Sync for CrcWriter<W>where
    W: Sync,

impl<R> Sync for DeflateEncoder<R>where
    R: Sync,

impl<R> Sync for DeflateDecoder<R>where
    R: Sync,

impl<R> Sync for DeflateEncoder<R>where
    R: Sync,

impl<R> Sync for DeflateDecoder<R>where
    R: Sync,

impl<W> Sync for DeflateEncoder<W>where
    W: Sync,

impl<W> Sync for DeflateDecoder<W>where
    W: Sync,

impl<R> Sync for GzEncoder<R>where
    R: Sync,

impl<R> Sync for GzDecoder<R>where
    R: Sync,

impl<R> Sync for MultiGzDecoder<R>where
    R: Sync,

impl<R> Sync for GzEncoder<R>where
    R: Sync,

impl<R> Sync for GzDecoder<R>where
    R: Sync,

impl<R> Sync for MultiGzDecoder<R>where
    R: Sync,

impl<W> Sync for GzEncoder<W>where
    W: Sync,

impl<W> Sync for GzDecoder<W>where
    W: Sync,

impl Sync for GzHeader

impl Sync for GzBuilder

impl Sync for Compress

impl Sync for Decompress

impl Sync for Status

impl<R> Sync for ZlibEncoder<R>where
    R: Sync,

impl<R> Sync for ZlibDecoder<R>where
    R: Sync,

impl<R> Sync for ZlibEncoder<R>where
    R: Sync,

impl<R> Sync for ZlibDecoder<R>where
    R: Sync,

impl<W> Sync for ZlibEncoder<W>where
    W: Sync,

impl<W> Sync for ZlibDecoder<W>where
    W: Sync,

impl Sync for Compression

impl Sync for FnvHasher

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

impl<V> Sync for FinalizationResult<V>where
    V: Sync,

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

impl<'a> Sync for Parse<'a>

impl<'a> Sync for ParseIntoOwned<'a>

impl<'a> Sync for ByteSerialize<'a>

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

impl Sync for Analysis

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

impl Sync for BlockCmd

impl Sync for MachineCmd

impl Sync for OverheadCmd

impl Sync for PalletCmd

impl Sync for StorageCmd

impl Sync for Error

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

impl Sync for Weight

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

impl Sync for Identity

impl Sync for Blake2_128

impl Sync for Blake2_256

impl Sync for Twox128

impl Sync for Twox256

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

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

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

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

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

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

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

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

impl Sync for OptionQuery

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

impl Sync for ValueQuery

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

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

impl<T> Sync for KeyPrefixIterator<T>

impl Sync for Instance1

impl Sync for Instance2

impl Sync for Instance3

impl Sync for Instance4

impl Sync for Instance5

impl Sync for Instance6

impl Sync for Instance7

impl Sync for Instance8

impl Sync for Instance9

impl Sync for Instance10

impl Sync for Instance11

impl Sync for Instance12

impl Sync for Instance13

impl Sync for Instance14

impl Sync for Instance15

impl Sync for Instance16

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

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

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

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

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

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

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

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

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

impl Sync for Everything

impl Sync for Nothing

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

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

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

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

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

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

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

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

impl Sync for Backing

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

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

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

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

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

impl Sync for LookupError

impl Sync for StorageInfo

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

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

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

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

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

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

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

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

impl Sync for Select

impl Sync for Pays

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

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

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

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

impl Sync for Never

impl Sync for PalletId

impl !Sync for StopParse

impl<P> !Sync for Braces<P>

impl<P> !Sync for Brackets<P>

impl<P> !Sync for Parens<P>

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

impl Sync for NoTrailing

impl Sync for Trailing

impl !Sync for Meta

impl Sync for BlockLength

impl Sync for ForAll

impl Sync for ForAny

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

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

impl<T> Sync for Account<T>where
    <T as SigningTypes>::Public: Sync,

impl<T> Sync for CheckGenesis<T>

impl<T> Sync for CheckMortality<T>

impl<T> Sync for CheckNonZeroSender<T>

impl<T> Sync for CheckNonce<T>

impl<T> Sync for CheckSpecVersion<T>

impl<T> Sync for CheckTxVersion<T>

impl<T> Sync for CheckWeight<T>

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

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

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

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

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

impl Sync for Phase

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

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

impl<AccountId> Sync for EnsureRoot<AccountId>where
    AccountId: Sync,

impl<AccountId, Success> Sync for EnsureRootWithSuccess<AccountId, Success>where
    AccountId: Sync,
    Success: Sync,

impl<AccountId> Sync for EnsureSigned<AccountId>where
    AccountId: Sync,

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

impl<AccountId> Sync for EnsureNone<AccountId>where
    AccountId: Sync,

impl<T> Sync for EnsureNever<T>where
    T: Sync,

impl Sync for RefStatus

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

impl<T> Sync for SelfSufficient<T>where
    T: Sync,

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

impl<T> Sync for ChainContext<T>where
    T: Sync,

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

impl Sync for FsStats

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

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

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

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

impl Sync for SendError

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

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

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

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

impl Sync for Canceled

impl !Sync for LocalPool

impl !Sync for LocalSpawner

impl<S> Sync for BlockingStream<S>where
    S: Sync,

impl Sync for ThreadPool

impl Sync for Enter

impl Sync for EnterError

impl<T> Sync for Pending<T>where
    T: Sync,

impl<F> Sync for PollOnce<F>where
    F: Sync,

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

impl<T> Sync for Ready<T>where
    T: Sync,

impl Sync for YieldNow

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

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

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

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

impl<F> Sync for CatchUnwind<F>where
    F: Sync,

impl<S> Sync for BlockOn<S>where
    S: Sync,

impl<T> Sync for Empty<T>where
    T: Sync,

impl<I> Sync for Iter<I>where
    I: Sync,

impl<T> Sync for Once<T>where
    T: Sync,

impl<T> Sync for Pending<T>where
    T: Sync,

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

impl<T> Sync for Repeat<T>where
    T: Sync,

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

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

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

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

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

impl<S: ?Sized> Sync for CountFuture<S>where
    S: Sync,

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

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

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

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

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

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

impl<S> Sync for Fuse<S>where
    S: Sync,

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

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

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

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

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

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

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

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

impl<S> Sync for Take<S>where
    S: Sync,

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

impl<S> Sync for Skip<S>where
    S: Sync,

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

impl<S> Sync for StepBy<S>where
    S: Sync,

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

impl<S> Sync for Cloned<S>where
    S: Sync,

impl<S> Sync for Copied<S>where
    S: Sync,

impl<S> Sync for Cycle<S>where
    S: Sync,

impl<S> Sync for Enumerate<S>where
    S: Sync,

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

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

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

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

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

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

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

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

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

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

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

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

impl<T> Sync for AssertAsync<T>where
    T: Sync,

impl<T> Sync for BlockOn<T>where
    T: Sync,

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

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

impl<T> Sync for Cursor<T>where
    T: Sync,

impl Sync for Empty

impl Sync for Repeat

impl Sync for Sink

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

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

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

impl<R> Sync for Lines<R>where
    R: Sync,

impl<R> Sync for Split<R>where
    R: Sync,

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

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

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

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

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

impl<R> Sync for Take<R>where
    R: Sync,

impl<R> Sync for Bytes<R>where
    R: Sync,

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

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

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

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

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

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

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

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

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

impl<IO> Sync for TlsStream<IO>where
    IO: Sync,

impl<IO> Sync for TlsStream<IO>where
    IO: Sync,

impl Sync for TlsAcceptor

impl<IO> Sync for LazyConfigAcceptor<IO>where
    IO: Sync,

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

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

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

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

impl<IO> Sync for FallibleAccept<IO>where
    IO: Sync,

impl<T> Sync for TlsStream<T>where
    T: Sync,

impl Sync for SpawnError

impl<'a> Sync for WakerRef<'a>

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

impl<'a, T> !Sync for FutureObj<'a, T>

impl Sync for Delay

impl<Fut> Sync for Fuse<Fut>where
    Fut: Sync,

impl<Fut> Sync for CatchUnwind<Fut>where
    Fut: Sync,

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

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

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

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

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

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

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

impl<F> Sync for IntoStream<F>where
    F: Sync,

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

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

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

impl<Fut> Sync for NeverError<Fut>where
    Fut: Sync,

impl<Fut> Sync for UnitError<Fut>where
    Fut: Sync,

impl<Fut> Sync for IntoFuture<Fut>where
    Fut: Sync,

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

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

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

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

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

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

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

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

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

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

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

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

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

impl<F> Sync for Lazy<F>where
    F: Sync,

impl<T> Sync for Pending<T>where
    T: Sync,

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

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

impl<F> Sync for OptionFuture<F>where
    F: Sync,

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

impl<T> Sync for PollImmediate<T>where
    T: Sync,

impl<T> Sync for Ready<T>where
    T: Sync,

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

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

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

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

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

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

impl<Fut> Sync for SelectAll<Fut>where
    Fut: Sync,

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

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

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

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

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

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

impl<Fut> Sync for SelectOk<Fut>where
    Fut: Sync,

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

impl Sync for AbortHandle

impl<T> Sync for Abortable<T>where
    T: Sync,

impl Sync for Aborted

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

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

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

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

impl<St> Sync for Cycle<St>where
    St: Sync,

impl<St> Sync for Enumerate<St>where
    St: Sync,

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

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

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

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

impl<St> Sync for Fuse<St>where
    St: Sync,

impl<St> Sync for StreamFuture<St>where
    St: Sync,

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

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

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

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

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

impl<'a, St> Sync for PeekMut<'a, St>where
    St: Sync,
    <St as Stream>::Item: Sync,

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

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

impl<St> Sync for Skip<St>where
    St: Sync,

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

impl<St> Sync for Take<St>where
    St: Sync,

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

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

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

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

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

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

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

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

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

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

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

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

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

impl<St> Sync for CatchUnwind<St>where
    St: Sync,

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

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

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

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

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

impl<St> Sync for IntoStream<St>where
    St: Sync,

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

impl<I> Sync for Iter<I>where
    I: Sync,

impl<T> Sync for Repeat<T>where
    T: Sync,

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

impl<T> Sync for Empty<T>where
    T: Sync,

impl<Fut> Sync for Once<Fut>where
    Fut: Sync,

impl<T> Sync for Pending<T>where
    T: Sync,

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

impl<S> Sync for PollImmediate<S>where
    S: Sync,

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

impl Sync for PollNext

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

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

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

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

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

impl<St> Sync for SelectAll<St>where
    St: Sync,

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

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

impl<St> Sync for IntoIter<St>where
    St: Sync,

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

impl<T> Sync for Drain<T>where
    T: Sync,

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

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

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

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

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

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

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

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

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

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

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

impl<T> Sync for AllowStdIo<T>where
    T: Sync,

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

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

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

impl<W> Sync for LineWriter<W>where
    W: Sync,

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

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

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

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

impl<'a, R, W: ?Sized> Sync for CopyBufAbortable<'a, R, W>where
    R: Sync,
    W: Sync,

impl<T> Sync for Cursor<T>where
    T: Sync,

impl Sync for Empty

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

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

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

impl<R> Sync for Lines<R>where
    R: Sync,

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

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

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

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

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

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

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

impl Sync for Repeat

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

impl Sync for Sink

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

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

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

impl<R> Sync for Take<R>where
    R: Sync,

impl<T> Sync for Window<T>where
    T: Sync,

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

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

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

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

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

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

impl Sync for FxHasher

impl Sync for FxHasher64

impl Sync for FxHasher32

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

impl Sync for Error

impl Sync for GHash

impl Sync for Format

impl Sync for Encoding

impl Sync for Register

impl<T> Sync for DebugAbbrevOffset<T>where
    T: Sync,

impl<T> Sync for DebugAddrBase<T>where
    T: Sync,

impl<T> Sync for DebugAddrIndex<T>where
    T: Sync,

impl<T> Sync for DebugArangesOffset<T>where
    T: Sync,

impl<T> Sync for DebugInfoOffset<T>where
    T: Sync,

impl<T> Sync for DebugLineOffset<T>where
    T: Sync,

impl<T> Sync for DebugLineStrOffset<T>where
    T: Sync,

impl<T> Sync for LocationListsOffset<T>where
    T: Sync,

impl<T> Sync for DebugLocListsBase<T>where
    T: Sync,

impl<T> Sync for DebugLocListsIndex<T>where
    T: Sync,

impl<T> Sync for DebugMacinfoOffset<T>where
    T: Sync,

impl<T> Sync for DebugMacroOffset<T>where
    T: Sync,

impl<T> Sync for RawRangeListsOffset<T>where
    T: Sync,

impl<T> Sync for RangeListsOffset<T>where
    T: Sync,

impl<T> Sync for DebugRngListsBase<T>where
    T: Sync,

impl<T> Sync for DebugRngListsIndex<T>where
    T: Sync,

impl<T> Sync for DebugStrOffset<T>where
    T: Sync,

impl<T> Sync for DebugStrOffsetsBase<T>where
    T: Sync,

impl<T> Sync for DebugStrOffsetsIndex<T>where
    T: Sync,

impl<T> Sync for DebugTypesOffset<T>where
    T: Sync,

impl<T> Sync for DebugFrameOffset<T>where
    T: Sync,

impl<T> Sync for EhFrameOffset<T>where
    T: Sync,

impl<T> Sync for UnitSectionOffset<T>where
    T: Sync,

impl Sync for SectionId

impl Sync for DwoId

impl Sync for Arm

impl Sync for AArch64

impl Sync for RiscV

impl Sync for X86

impl Sync for X86_64

impl Sync for DwSect

impl Sync for DwSectV2

impl Sync for DwUt

impl Sync for DwCfa

impl Sync for DwChildren

impl Sync for DwTag

impl Sync for DwAt

impl Sync for DwForm

impl Sync for DwAte

impl Sync for DwLle

impl Sync for DwDs

impl Sync for DwEnd

impl Sync for DwAccess

impl Sync for DwVis

impl Sync for DwLang

impl Sync for DwAddr

impl Sync for DwId

impl Sync for DwCc

impl Sync for DwInl

impl Sync for DwOrd

impl Sync for DwDsc

impl Sync for DwIdx

impl Sync for DwDefaulted

impl Sync for DwLns

impl Sync for DwLne

impl Sync for DwLnct

impl Sync for DwMacro

impl Sync for DwRle

impl Sync for DwOp

impl Sync for DwEhPe

impl Sync for BigEndian

impl<R> Sync for DebugAddr<R>where
    R: Sync,

impl<R> Sync for DebugFrame<R>where
    R: Sync,

impl<R> Sync for EhFrameHdr<R>where
    R: Sync,

impl<R> Sync for ParsedEhFrameHdr<R>where
    R: Sync,

impl<'a, 'bases, R> Sync for EhHdrTableIter<'a, 'bases, R>where
    R: Sync,

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

impl<R> Sync for EhFrame<R>where
    R: Sync,

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

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

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

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

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

impl<R, A> Sync for UnwindContext<R, A>where
    R: Sync,
    <<A as UnwindContextStorage<R>>::Stack as Sealed>::Storage: Sync,

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

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

impl<R, S> Sync for UnwindTableRow<R, S>where
    R: Sync,
    <<S as UnwindContextStorage<R>>::Rules as Sealed>::Storage: Sync,

impl<R> Sync for CfaRule<R>where
    R: Sync,

impl<R> Sync for RegisterRule<R>where
    R: Sync,

impl<R> Sync for CallFrameInstruction<R>where
    R: Sync,

impl<'a, R> Sync for CallFrameInstructionIter<'a, R>where
    R: Sync,

impl Sync for Pointer

impl<R> Sync for Dwarf<R>where
    R: Send + Sync,

impl<R> Sync for DwarfPackage<R>where
    R: Sync,

impl<R, Offset> Sync for Unit<R, Offset>where
    Offset: Sync,
    R: Sync,

impl<R> Sync for RangeIter<R>where
    R: Sync,
    <R as Reader>::Offset: Sync,

impl<'input, Endian> Sync for EndianSlice<'input, Endian>where
    Endian: Sync,

impl<R> Sync for DebugAbbrev<R>where
    R: Sync,

impl<R> Sync for DebugAranges<R>where
    R: Sync,

impl<R> Sync for ArangeHeaderIter<R>where
    R: Sync,
    <R as Reader>::Offset: Sync,

impl<R, Offset> Sync for ArangeHeader<R, Offset>where
    Offset: Sync,
    R: Sync,

impl<R> Sync for ArangeEntryIter<R>where
    R: Sync,

impl Sync for ArangeEntry

impl<R> Sync for DebugCuIndex<R>where
    R: Sync,

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

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

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

impl<R> Sync for DebugLine<R>where
    R: Sync,

impl<R, Program, Offset> Sync for LineRows<R, Program, Offset>where
    Program: Sync,
    R: Sync,

impl<R, Offset> Sync for LineInstruction<R, Offset>where
    Offset: Sync,
    R: Sync,

impl<R> Sync for LineInstructions<R>where
    R: Sync,

impl Sync for LineRow

impl Sync for ColumnType

impl<R> Sync for LineSequence<R>where
    R: Sync,

impl<R, Offset> Sync for LineProgramHeader<R, Offset>where
    Offset: Sync,
    R: Sync,

impl<R, Offset> Sync for IncompleteLineProgram<R, Offset>where
    Offset: Sync,
    R: Sync,

impl<R, Offset> Sync for CompleteLineProgram<R, Offset>where
    Offset: Sync,
    R: Sync,

impl<R, Offset> Sync for FileEntry<R, Offset>where
    Offset: Sync,
    R: Sync,

impl<R> Sync for DebugLoc<R>where
    R: Sync,

impl<R> Sync for DebugLocLists<R>where
    R: Sync,

impl<R> Sync for LocationLists<R>where
    R: Sync,

impl<R> Sync for RawLocListIter<R>where
    R: Sync,

impl<R> Sync for RawLocListEntry<R>where
    R: Sync,
    <R as Reader>::Offset: Sync,

impl<R> Sync for LocListIter<R>where
    R: Sync,
    <R as Reader>::Offset: Sync,

impl<R> Sync for LocationListEntry<R>where
    R: Sync,

impl<T> Sync for DieReference<T>where
    T: Sync,

impl<R, Offset> Sync for Operation<R, Offset>where
    Offset: Sync,
    R: Sync,

impl<R, Offset> Sync for Location<R, Offset>where
    Offset: Sync,
    R: Sync,

impl<R, Offset> Sync for Piece<R, Offset>where
    Offset: Sync,
    R: Sync,

impl<R> Sync for EvaluationResult<R>where
    R: Sync,
    <R as Reader>::Offset: Sync,

impl<R> Sync for Expression<R>where
    R: Sync,

impl<R> Sync for OperationIter<R>where
    R: Sync,

impl<R, S> Sync for Evaluation<R, S>where
    R: Sync,
    <<S as EvaluationStorage<R>>::ExpressionStack as Sealed>::Storage: Sync,
    <<S as EvaluationStorage<R>>::Result as Sealed>::Storage: Sync,
    <<S as EvaluationStorage<R>>::Stack as Sealed>::Storage: Sync,

impl<R> Sync for PubNamesEntry<R>where
    R: Sync,
    <R as Reader>::Offset: Sync,

impl<R> Sync for DebugPubNames<R>where
    R: Sync,
    <R as Reader>::Offset: Sync,

impl<R> Sync for PubNamesEntryIter<R>where
    R: Sync,
    <R as Reader>::Offset: Sync,

impl<R> Sync for PubTypesEntry<R>where
    R: Sync,
    <R as Reader>::Offset: Sync,

impl<R> Sync for DebugPubTypes<R>where
    R: Sync,
    <R as Reader>::Offset: Sync,

impl<R> Sync for PubTypesEntryIter<R>where
    R: Sync,
    <R as Reader>::Offset: Sync,

impl<R> Sync for DebugRanges<R>where
    R: Sync,

impl<R> Sync for DebugRngLists<R>where
    R: Sync,

impl<R> Sync for RangeLists<R>where
    R: Sync,

impl<R> Sync for RawRngListIter<R>where
    R: Sync,

impl<T> Sync for RawRngListEntry<T>where
    T: Sync,

impl<R> Sync for RngListIter<R>where
    R: Sync,
    <R as Reader>::Offset: Sync,

impl Sync for Range

impl<R> Sync for DebugStr<R>where
    R: Sync,

impl<R> Sync for DebugStrOffsets<R>where
    R: Sync,

impl<R> Sync for DebugLineStr<R>where
    R: Sync,

impl<R> Sync for DebugInfo<R>where
    R: Sync,

impl<R> Sync for DebugInfoUnitHeadersIter<R>where
    R: Sync,
    <R as Reader>::Offset: Sync,

impl<Offset> Sync for UnitType<Offset>where
    Offset: Sync,

impl<R, Offset> Sync for UnitHeader<R, Offset>where
    Offset: Sync,
    R: Sync,

impl<'abbrev, 'unit, R, Offset = <R as Reader>::Offset> !Sync for DebuggingInformationEntry<'abbrev, 'unit, R, Offset>

impl<R, Offset> Sync for AttributeValue<R, Offset>where
    Offset: Sync,
    R: Sync,

impl<R> Sync for Attribute<R>where
    R: Sync,
    <R as Reader>::Offset: Sync,

impl<'abbrev, 'entry, 'unit, R> !Sync for AttrsIter<'abbrev, 'entry, 'unit, R>

impl<'abbrev, 'unit, R> Sync for EntriesRaw<'abbrev, 'unit, R>where
    R: Sync,
    <R as Reader>::Offset: Sync,

impl<'abbrev, 'unit, R> !Sync for EntriesCursor<'abbrev, 'unit, R>

impl<'abbrev, 'unit, R> !Sync for EntriesTree<'abbrev, 'unit, R>

impl<'abbrev, 'unit, 'tree, R> !Sync for EntriesTreeNode<'abbrev, 'unit, 'tree, R>

impl<'abbrev, 'unit, 'tree, R> !Sync for EntriesTreeIter<'abbrev, 'unit, 'tree, R>

impl<R> Sync for DebugTypes<R>where
    R: Sync,

impl<R> Sync for DebugTypesUnitHeadersIter<R>where
    R: Sync,
    <R as Reader>::Offset: Sync,

impl Sync for ValueType

impl Sync for Value

impl<T> Sync for UnitOffset<T>where
    T: Sync,

impl Sync for StoreOnHeap

impl Sync for Error

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

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

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

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

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

impl Sync for CieId

impl Sync for FrameTable

impl Sync for Dwarf

impl Sync for DwarfUnit

impl Sync for FileId

impl Sync for LineProgram

impl Sync for LineRow

impl Sync for LineString

impl Sync for DirectoryId

impl Sync for FileInfo

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

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

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

impl Sync for Location

impl Sync for Expression

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

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

impl Sync for RangeListId

impl Sync for RangeList

impl Sync for Range

impl Sync for StringId

impl Sync for StringTable

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

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

impl Sync for UnitId

impl Sync for UnitEntryId

impl Sync for UnitTable

impl Sync for Unit

impl Sync for Attribute

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

impl Sync for Error

impl Sync for Address

impl Sync for Reference

impl Sync for Glob

impl Sync for GlobMatcher

impl<'a> Sync for GlobBuilder<'a>

impl Sync for Error

impl Sync for ErrorKind

impl Sync for GlobSet

impl<'a> Sync for Candidate<'a>

impl Sync for Error

impl Sync for Reason

impl<B> Sync for SendRequest<B>where
    B: Send,

impl<B> Sync for ReadySendRequest<B>where
    B: Send,

impl<T, B> Sync for Connection<T, B>where
    B: Send + Sync,
    T: Sync,

impl Sync for PushPromise

impl Sync for Builder

impl Sync for Protocol

impl<T, B> Sync for Handshake<T, B>where
    B: Sync,
    T: Sync,

impl<T, B> Sync for Connection<T, B>where
    B: Send + Sync,
    T: Sync,

impl Sync for Builder

impl<B> Sync for SendResponse<B>where
    B: Send,

impl<B> Sync for SendPushedResponse<B>where
    B: Send,

impl<B> Sync for SendStream<B>where
    B: Send,

impl Sync for StreamId

impl Sync for RecvStream

impl Sync for FlowControl

impl Sync for PingPong

impl Sync for Ping

impl Sync for Pong

impl Sync for bf16

impl Sync for f16

impl<'reg> Sync for BlockParams<'reg>

impl<'reg> Sync for BlockContext<'reg>

impl Sync for Context

impl Sync for RenderError

impl Sync for Path

impl<'reg, 'rc> Sync for ScopedJson<'reg, 'rc>

impl<'reg, 'rc> Sync for PathAndJson<'reg, 'rc>

impl<'reg> Sync for Registry<'reg>

impl<'reg, 'rc> !Sync for RenderContext<'reg, 'rc>

impl<'reg, 'rc> Sync for Helper<'reg, 'rc>

impl<'reg, 'rc> Sync for Decorator<'reg, 'rc>

impl Sync for Template

impl Sync for BlockParam

impl Sync for Parameter

impl<T> !Sync for Bucket<T>

impl<T> Sync for RawIter<T>

impl<'a, T, A = Global> !Sync for RawIterHash<'a, T, A>

impl<K, V, S, A> Sync for HashMap<K, V, S, A>where
    A: Sync,
    K: Sync,
    S: Sync,
    V: Sync,

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

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

impl<K, V, A> Sync for IntoIter<K, V, A>where
    A: Sync,
    K: Sync,
    V: Sync,

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

impl<K, V, A> Sync for IntoValues<K, V, A>where
    A: Sync,
    K: Sync,
    V: Sync,

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

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

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

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

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

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

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

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

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

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

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

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

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

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

impl<T, S, A> Sync for HashSet<T, S, A>where
    A: Sync,
    S: Sync,
    T: Sync,

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

impl<T> Sync for HexFmt<T>where
    T: Sync,

impl<T> Sync for HexList<T>where
    T: Sync,

impl<D> Sync for Hmac<D>where
    D: Sync,

impl<D> Sync for HmacDRBG<D>

impl<T> Sync for HeaderMap<T>where
    T: Sync,

impl<T> Sync for IntoIter<T>where
    T: Sync,

impl<'a, T> Sync for Keys<'a, T>where
    T: Sync,

impl<'a, T> Sync for Values<'a, T>where
    T: Sync,

impl<'a, T> Sync for ValuesMut<'a, T>where
    T: Sync,

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

impl<'a, T> Sync for Entry<'a, T>where
    T: Sync,

impl<'a, T> Sync for VacantEntry<'a, T>where
    T: Sync,

impl<'a, T> Sync for OccupiedEntry<'a, T>where
    T: Sync,

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

impl Sync for HeaderName

impl Sync for HeaderValue

impl Sync for ToStrError

impl Sync for Method

impl<T> Sync for Request<T>where
    T: Sync,

impl Sync for Parts

impl Sync for Builder

impl<T> Sync for Response<T>where
    T: Sync,

impl Sync for Parts

impl Sync for Builder

impl Sync for StatusCode

impl Sync for Authority

impl Sync for Builder

impl<T> Sync for Port<T>where
    T: Sync,

impl Sync for Scheme

impl Sync for Uri

impl Sync for Parts

impl Sync for InvalidUri

impl Sync for Version

impl Sync for Error

impl Sync for Extensions

impl<D> Sync for Empty<D>

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

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

impl<'a, T: ?Sized> Sync for Data<'a, T>where
    T: Sync,

impl<'a, T: ?Sized> Sync for Trailers<'a, T>where
    T: Sync,

impl Sync for SizeHint

impl<D, E> Sync for BoxBody<D, E>

impl<D, E> !Sync for UnsyncBoxBody<D, E>

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

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

impl Sync for Error

impl<T> Sync for Status<T>where
    T: Sync,

impl<'headers, 'buf> Sync for Request<'headers, 'buf>

impl<'headers, 'buf> Sync for Response<'headers, 'buf>

impl<'a> Sync for Header<'a>

impl Sync for HttpDate

impl Sync for Error

impl Sync for Error

impl Sync for Duration

impl Sync for Timestamp

impl Sync for Error

impl<Balance> Sync for AssetReserveState<Balance>where
    Balance: Sync,

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

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

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

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

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

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

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

impl Sync for Ratio

impl Sync for Rounding

impl Sync for MathError

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

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

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

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

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

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

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

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

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

impl Sync for Body

impl Sync for Sender

impl Sync for Error

impl Sync for Protocol

impl !Sync for Upgraded

impl Sync for OnUpgrade

impl<T> Sync for Parts<T>where
    T: Sync,

impl Sync for Name

impl Sync for GaiResolver

impl Sync for GaiAddrs

impl Sync for GaiFuture

impl<R> Sync for HttpConnector<R>where
    R: Sync,

impl Sync for HttpInfo

impl Sync for Connected

impl<C, B> Sync for Client<C, B>where
    B: Send,
    C: Sync,

impl Sync for Builder

impl<B> Sync for SendRequest<B>where
    B: Send,

impl<T, B> Sync for Connection<T, B>where
    B: Send + Sync,
    T: Sync,
    <B as Body>::Data: Send + Sync,

impl Sync for Builder

impl<T> Sync for Parts<T>where
    T: Sync,

impl<C, B, T> Sync for Connect<C, B, T>where
    C: Sync,

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

impl Sync for AddrStream

impl<E> Sync for Http<E>where
    E: Sync,

impl<T, S, E> Sync for Connection<T, S, E>where
    E: Sync,
    S: Sync,
    T: Sync,
    <<S as HttpService<Body>>::ResBody as Body>::Data: Send + Sync,
    <S as HttpService<Body>>::Future: Sync,
    <S as HttpService<Body>>::ResBody: Sync,

impl<T, S> Sync for Parts<T, S>where
    S: Sync,
    T: Sync,

impl<I, S, E> Sync for Server<I, S, E>where
    E: Sync,
    I: Sync,
    S: Sync,

impl<I, E> Sync for Builder<I, E>where
    E: Sync,
    I: Sync,

impl<State> Sync for ConnectorBuilder<State>where
    State: Sync,

impl<T> Sync for HttpsConnector<T>where
    T: Sync,

impl<T> Sync for MaybeHttpsStream<T>where
    T: Sync,

impl Sync for Idna

impl Sync for Config

impl Sync for Errors

impl Sync for IfEvent

impl Sync for IfWatcher

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

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

impl<K, V, S> Sync for IndexMap<K, V, S>where
    K: Sync,
    S: Sync,
    V: Sync,

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

impl<K, V> Sync for IntoKeys<K, V>where
    K: Sync,
    V: Sync,

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

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

impl<K, V> Sync for IntoValues<K, V>where
    K: Sync,
    V: Sync,

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

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

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

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

impl<T, S> Sync for IndexSet<T, S>where
    S: Sync,
    T: Sync,

impl<T> Sync for IntoIter<T>where
    T: Sync,

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

impl<'a, T> Sync for Drain<'a, T>where
    T: Sync,

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

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

impl<'a, T, S1, S2> Sync for SymmetricDifference<'a, T, S1, S2>where
    S1: Sync,
    S2: Sync,
    T: Sync,

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

impl<'inp, 'out, T> !Sync for InOut<'inp, 'out, T>

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

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

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

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

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

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

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

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

impl<'fd> Sync for BorrowedFd<'fd>

impl Sync for OwnedFd

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

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

impl Sync for IpNetwork

impl Sync for Ipv4Network

impl Sync for Ipv6Network

impl Sync for IpAddrRange

impl Sync for IpNet

impl Sync for Ipv4Net

impl Sync for Ipv6Net

impl Sync for IpSubnets

impl Sync for Ipv4Subnets

impl Sync for Ipv6Subnets

impl<I, J> Sync for Interleave<I, J>where
    I: Sync,
    J: Sync,

impl<I, J> Sync for InterleaveShortest<I, J>where
    I: Sync,
    J: Sync,

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

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

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

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

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

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

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

impl<I> Sync for WhileSome<I>where
    I: Sync,

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

impl<I, F> Sync for Positions<I, F>where
    F: Sync,
    I: Sync,

impl<I, F> Sync for Update<I, F>where
    F: Sync,
    I: Sync,

impl<I> Sync for Step<I>where
    I: Sync,

impl<I> Sync for MultiProduct<I>where
    I: Sync,
    <I as Iterator>::Item: Sync,

impl<I> Sync for Combinations<I>where
    I: Sync,
    <I as Iterator>::Item: Sync,

impl<I> Sync for CombinationsWithReplacement<I>where
    I: Sync,
    <I as Iterator>::Item: Sync,

impl<I, J> Sync for ConsTuples<I, J>where
    I: Sync,

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

impl<'a, I> !Sync for Format<'a, I>

impl<'a, I, F> !Sync for FormatWith<'a, I, F>

impl<I, T, E> Sync for FlattenOk<I, T, E>where
    I: Sync,
    <T as IntoIterator>::IntoIter: Sync,

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

impl<I> !Sync for IntoChunks<I>

impl<'a, I> !Sync for Chunk<'a, I>

impl<'a, I> !Sync for Chunks<'a, I>

impl<K, I, F> !Sync for GroupBy<K, I, F>

impl<'a, K, I, F> !Sync for Group<'a, K, I, F>

impl<'a, K, I, F> !Sync for Groups<'a, K, I, F>

impl<I, ElemF> Sync for IntersperseWith<I, ElemF>where
    ElemF: Sync,
    I: Sync,
    <I as Iterator>::Item: Sync,

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

impl<I, J, F> Sync for MergeJoinBy<I, J, F>where
    F: Sync,
    I: Sync,
    J: Sync,
    <I as Iterator>::Item: Sync,
    <J as Iterator>::Item: Sync,

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

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

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

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

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

impl<'a, I, E> Sync for ProcessResults<'a, I, E>where
    E: Sync,
    I: Sync,

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

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

impl<I> !Sync for RcIter<I>

impl<A> Sync for RepeatN<A>where
    A: Sync,

impl<F> Sync for RepeatCall<F>where
    F: Sync,

impl<St, F> Sync for Unfold<St, F>where
    F: Sync,
    St: Sync,

impl<St, F> Sync for Iterate<St, F>where
    F: Sync,
    St: Sync,

impl<I> !Sync for Tee<I>

impl<T> Sync for TupleBuffer<T>where
    <T as TupleCollect>::Buffer: Sync,

impl<I, T> Sync for TupleWindows<I, T>where
    I: Sync,
    T: Sync,

impl<I, T> Sync for CircularTupleWindows<I, T>where
    I: Sync,
    T: Sync,

impl<I, T> Sync for Tuples<I, T>where
    I: Sync,
    <T as TupleCollect>::Buffer: Sync,

impl<I> Sync for Unique<I>where
    I: Sync,
    <I as Iterator>::Item: Sync,

impl<I, V, F> Sync for UniqueBy<I, V, F>where
    F: Sync,
    I: Sync,
    V: Sync,

impl<I> Sync for WithPosition<I>where
    I: Sync,
    <I as Iterator>::Item: Sync,

impl<I, J> Sync for ZipEq<I, J>where
    I: Sync,
    J: Sync,

impl<T, U> Sync for ZipLongest<T, U>where
    T: Sync,
    U: Sync,

impl<T> Sync for Zip<T>where
    T: Sync,

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

impl<I, J> Sync for Diff<I, J>where
    I: Sync,
    J: Sync,
    <I as Iterator>::Item: Sync,
    <J as Iterator>::Item: Sync,

impl<T> Sync for MinMaxResult<T>where
    T: Sync,

impl<T> Sync for Position<T>where
    T: Sync,

impl<T> Sync for FoldWhile<T>where
    T: Sync,

impl Sync for Buffer

impl !Sync for CompileError

impl !Sync for Instance

impl !Sync for LinkError

impl !Sync for RuntimeError

impl !Sync for Module

impl !Sync for Table

impl !Sync for Global

impl !Sync for Memory

impl !Sync for Collator

impl !Sync for NumberFormat

impl !Sync for PluralRules

impl !Sync for Array

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

impl !Sync for ArrayBuffer

impl !Sync for BigInt

impl !Sync for Boolean

impl !Sync for DataView

impl !Sync for Error

impl !Sync for EvalError

impl !Sync for Function

impl !Sync for Generator

impl !Sync for Map

impl !Sync for Iterator

impl<'a> !Sync for Iter<'a>

impl !Sync for IntoIter

impl !Sync for IteratorNext

impl !Sync for Number

impl !Sync for Date

impl !Sync for Object

impl !Sync for Proxy

impl !Sync for RangeError

impl !Sync for RegExp

impl !Sync for Set

impl !Sync for SyntaxError

impl !Sync for TypeError

impl !Sync for UriError

impl !Sync for WeakMap

impl !Sync for WeakSet

impl !Sync for JsString

impl !Sync for Symbol

impl !Sync for Promise

impl !Sync for Int8Array

impl !Sync for Int16Array

impl !Sync for Int32Array

impl !Sync for Uint8Array

impl !Sync for Uint16Array

impl !Sync for Uint32Array

impl !Sync for Float32Array

impl !Sync for Float64Array

impl Sync for Sender

impl Sync for Receiver

impl Sync for Mode

impl Sync for WsError

impl Sync for Target

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

impl Sync for Error

impl Sync for Origin

impl Sync for AllowOrigin

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

impl Sync for Port

impl Sync for Host

impl Sync for AllowHosts

impl Sync for MethodSink

impl Sync for Resources

impl<'a> Sync for ConnState<'a>

impl Sync for MethodKind

impl<T> !Sync for MethodResult<T>

impl<'a> Sync for MethodResourcesBuilder<'a>

impl Sync for Methods

impl<Context> Sync for RpcModule<Context>where
    Context: Send + Sync,

impl Sync for MethodKind

impl Sync for Client

impl<Notif> Sync for Subscription<Notif>where
    Notif: Sync,

impl Sync for FrontToBack

impl<T> Sync for RequestIdGuard<T>where
    T: Sync,

impl Sync for IdKind

impl Sync for RpcTracing

impl<M> Sync for Builder<M>where
    M: Sync,

impl<M> Sync for Server<M>where
    M: Sync,

impl<'a> Sync for Params<'a>

impl<'a> Sync for ParamsSequence<'a>

impl<'a> Sync for ParamsSer<'a>

impl<'a> Sync for SubscriptionId<'a>

impl<'a> Sync for Id<'a>

impl<'a> Sync for Request<'a>

impl<'a> Sync for InvalidRequest<'a>

impl<'a, T> Sync for Notification<'a, T>where
    T: Sync,

impl<'a> Sync for RequestSer<'a>

impl<'a> Sync for NotificationSer<'a>

impl<'a, T> Sync for Response<'a, T>where
    T: Sync,

impl<'a, T> Sync for SubscriptionPayload<'a, T>where
    T: Sync,

impl<'a, T> Sync for SubscriptionPayloadError<'a, T>where
    T: Sync,

impl<'a> Sync for ErrorResponse<'a>

impl<'a> Sync for ErrorObject<'a>

impl Sync for ErrorCode

impl Sync for CallError

impl<M> Sync for Server<M>where
    M: Sync,

impl<M> Sync for Builder<M>where
    M: Sync,

impl Sync for AffinePoint

impl Sync for Scalar

impl Sync for Signature

impl Sync for Id

impl Sync for SigningKey

impl Sync for Secp256k1

impl Sync for KsmLocation

impl Sync for Ancestry

impl Sync for Kusama

impl Sync for Statemine

impl Sync for XcmConfig

impl Sync for MaxVotes

impl Sync for MaxVoters

impl Sync for BaseFilter

impl Sync for Version

impl Sync for SS58Prefix

impl Sync for MaxLocks

impl Sync for MaxReserves

impl Sync for Period

impl Sync for Offset

impl Sync for SessionKeys

impl Sync for SignedPhase

impl Sync for EraPayout

impl Sync for SpendPeriod

impl Sync for Burn

impl Sync for MaxKeys

impl Sync for Prefix

impl Sync for DepositBase

impl Sync for MaxFriends

impl Sync for MaxStrikes

impl Sync for PeriodSpend

impl Sync for MaxProxies

impl Sync for MaxPending

impl Sync for ProxyType

impl Sync for ParaDeposit

impl Sync for LeasePeriod

impl Sync for CrowdloanId

impl Sync for QueueCount

impl Sync for MaxQueueLen

impl Sync for GiltPeriod

impl Sync for MinFreeze

impl Sync for Runtime

impl Sync for Event

impl !Sync for Origin

impl Sync for PalletInfo

impl Sync for Call

impl Sync for RuntimeApi

impl Sync for WeightToFee

impl Sync for Kind

impl Sync for IoStats

impl Sync for DBOp

impl Sync for InMemory

impl Sync for Database

impl Sync for statvfs

impl Sync for max_align_t

impl Sync for clone_args

impl Sync for sigaction

impl Sync for statfs

impl Sync for flock

impl Sync for flock64

impl Sync for siginfo_t

impl !Sync for stack_t

impl Sync for stat

impl Sync for stat64

impl Sync for statfs64

impl Sync for statvfs64

impl !Sync for user

impl !Sync for mcontext_t

impl Sync for ipc_perm

impl Sync for shmid_ds

impl !Sync for ucontext_t

impl Sync for sigset_t

impl Sync for sysinfo

impl Sync for msqid_ds

impl Sync for semid_ds

impl Sync for sem_t

impl Sync for statx

impl !Sync for aiocb

impl Sync for __timeval

impl !Sync for glob64_t

impl !Sync for msghdr

impl Sync for cmsghdr

impl Sync for termios

impl Sync for mallinfo

impl Sync for mallinfo2

impl Sync for nl_pktinfo

impl Sync for nl_mmap_req

impl Sync for nl_mmap_hdr

impl !Sync for rtentry

impl Sync for timex

impl Sync for ntptimeval

impl !Sync for regex_t

impl Sync for Elf64_Chdr

impl Sync for Elf32_Chdr

impl Sync for seminfo

impl Sync for utmpx

impl Sync for termios2

impl Sync for open_how

impl Sync for fpos64_t

impl Sync for rlimit64

impl !Sync for glob_t

impl !Sync for passwd

impl !Sync for spwd

impl Sync for dqblk

impl Sync for itimerspec

impl Sync for fsid_t

impl Sync for packet_mreq

impl Sync for cpu_set_t

impl !Sync for if_nameindex

impl Sync for msginfo

impl Sync for sembuf

impl Sync for input_event

impl Sync for input_id

impl Sync for input_mask

impl Sync for ff_replay

impl Sync for ff_trigger

impl Sync for ff_envelope

impl Sync for ff_effect

impl !Sync for dl_phdr_info

impl Sync for Elf32_Ehdr

impl Sync for Elf64_Ehdr

impl Sync for Elf32_Sym

impl Sync for Elf64_Sym

impl Sync for Elf32_Phdr

impl Sync for Elf64_Phdr

impl Sync for Elf32_Shdr

impl Sync for Elf64_Shdr

impl Sync for ucred

impl !Sync for mntent

impl Sync for genlmsghdr

impl Sync for in6_pktinfo

impl Sync for sockaddr_vm

impl Sync for regmatch_t

impl Sync for can_filter

impl Sync for sock_filter

impl !Sync for sock_fprog

impl Sync for nlmsghdr

impl Sync for nlmsgerr

impl Sync for nlattr

impl Sync for in6_ifreq

impl Sync for sockaddr_nl

impl Sync for dirent

impl Sync for dirent64

impl Sync for af_alg_iv

impl Sync for mq_attr

impl !Sync for ifreq

impl Sync for sock_txtime

impl Sync for can_frame

impl Sync for canfd_frame

impl Sync for timezone

impl Sync for in_addr

impl Sync for ip_mreq

impl Sync for ip_mreqn

impl Sync for sockaddr

impl Sync for sockaddr_in

impl !Sync for addrinfo

impl Sync for sockaddr_ll

impl Sync for fd_set

impl !Sync for tm

impl Sync for sched_param

impl !Sync for Dl_info

impl !Sync for lconv

impl Sync for in_pktinfo

impl !Sync for ifaddrs

impl Sync for in6_rtmsg

impl Sync for arpreq

impl Sync for arpreq_old

impl Sync for arphdr

impl !Sync for mmsghdr

impl Sync for epoll_event

impl Sync for sockaddr_un

impl Sync for utsname

impl !Sync for sigevent

impl Sync for in6_addr

impl Sync for DIR

impl !Sync for group

impl Sync for utimbuf

impl Sync for timeval

impl Sync for timespec

impl Sync for rlimit

impl Sync for rusage

impl Sync for ipv6_mreq

impl !Sync for hostent

impl !Sync for iovec

impl Sync for pollfd

impl Sync for winsize

impl Sync for linger

impl !Sync for sigval

impl Sync for itimerval

impl Sync for tms

impl !Sync for servent

impl !Sync for protoent

impl Sync for FILE

impl Sync for fpos_t

impl<TInner> Sync for BandwidthLogging<TInner>where
    TInner: Sync,

impl<TInner> Sync for BandwidthFuture<TInner>where
    TInner: Sync,

impl<TInner> Sync for BandwidthConnecLogging<TInner>where
    TInner: Sync,

impl<F> Sync for SimpleProtocol<F>where
    F: Send + Sync,

impl Sync for Config

impl Sync for NatStatus

impl Sync for ProbeId

impl Sync for Event

impl !Sync for Behaviour

impl Sync for PeerId

impl Sync for Endpoint

impl<A, B> Sync for EitherError<A, B>where
    A: Sync,
    B: Sync,

impl<A, B> Sync for EitherOutput<A, B>where
    A: Sync,
    B: Sync,

impl<A, B> Sync for EitherOutbound<A, B>where
    <A as StreamMuxer>::OutboundSubstream: Sync,
    <B as StreamMuxer>::OutboundSubstream: Sync,

impl<A, B> Sync for EitherFuture<A, B>where
    A: Sync,
    B: Sync,

impl<A, B> Sync for EitherFuture2<A, B>where
    A: Sync,
    B: Sync,

impl<A, B> Sync for EitherName<A, B>where
    A: Sync,
    B: Sync,

impl<A, B> Sync for EitherTransport<A, B>where
    A: Sync,
    B: Sync,

impl Sync for Keypair

impl Sync for PublicKey

impl Sync for SecretKey

impl Sync for Keypair

impl Sync for PublicKey

impl Sync for Keypair

impl Sync for SecretKey

impl Sync for PublicKey

impl Sync for Keypair

impl Sync for PublicKey

impl !Sync for SubstreamBox

impl<TSocket> !Sync for SingletonMuxer<TSocket>

impl<T> Sync for StreamMuxerEvent<T>where
    T: Sync,

impl Sync for PeerRecord

impl<T, C> Sync for AndThen<T, C>where
    C: Sync,
    T: Sync,

impl<TFut, TMap, TMapOut> Sync for AndThenFuture<TFut, TMap, TMapOut>where
    TFut: Sync,
    TMap: Sync,
    TMapOut: Sync,

impl<A, B> Sync for OrTransport<A, B>where
    A: Sync,
    B: Sync,

impl<TOut> Sync for DummyTransport<TOut>where
    TOut: Sync,

impl Sync for DummyStream

impl<T, F> Sync for Map<T, F>where
    F: Sync,
    T: Sync,

impl<T, F> Sync for MapFuture<T, F>where
    F: Sync,
    T: Sync,

impl<T, F> Sync for MapErr<T, F>where
    F: Sync,
    T: Sync,

impl<T, F> Sync for MapErrListenerUpgrade<T, F>where
    F: Sync,
    <T as Transport>::ListenerUpgrade: Sync,

impl<T, F> Sync for MapErrDial<T, F>where
    F: Sync,
    <T as Transport>::Dial: Sync,

impl Sync for DialFuture

impl Sync for Listener

impl<T> Sync for Chan<T>where
    T: Send,

impl<InnerTrans> Sync for TransportTimeout<InnerTrans>where
    InnerTrans: Sync,

impl<InnerFut> Sync for Timeout<InnerFut>where
    InnerFut: Sync,

impl<TErr> Sync for TransportTimeoutError<TErr>where
    TErr: Sync,

impl<T> Sync for Builder<T>where
    T: Sync,

impl<C, U> Sync for Authenticate<C, U>where
    C: Sync,
    U: Sync,
    <U as InboundUpgrade<Negotiated<C>>>::Future: Sync,
    <U as OutboundUpgrade<Negotiated<C>>>::Future: Sync,
    <U as UpgradeInfo>::Info: Sync,
    <<U as UpgradeInfo>::InfoIter as IntoIterator>::IntoIter: Sync,

impl<C, U> Sync for Multiplex<C, U>where
    C: Sync,
    U: Sync,
    <U as InboundUpgrade<Negotiated<C>>>::Future: Sync,
    <U as OutboundUpgrade<Negotiated<C>>>::Future: Sync,
    <U as UpgradeInfo>::Info: Sync,
    <<U as UpgradeInfo>::InfoIter as IntoIterator>::IntoIter: Sync,

impl<T> Sync for Authenticated<T>where
    T: Sync,

impl<T> Sync for Multiplexed<T>where
    T: Sync,

impl<T, U> Sync for Upgrade<T, U>where
    T: Sync,
    U: Sync,

impl<T, U> Sync for TransportUpgradeError<T, U>where
    T: Sync,
    U: Sync,

impl<F, U, C> Sync for DialUpgradeFuture<F, U, C>where
    C: Sync,
    F: Sync,
    U: Sync,
    <U as OutboundUpgrade<Negotiated<C>>>::Future: Sync,
    <U as UpgradeInfo>::Info: Sync,
    <<U as UpgradeInfo>::InfoIter as IntoIterator>::IntoIter: Sync,

impl<F, U, C> Sync for ListenerUpgradeFuture<F, U, C>where
    C: Sync,
    F: Sync,
    U: Sync,
    <U as InboundUpgrade<Negotiated<C>>>::Future: Sync,
    <U as UpgradeInfo>::Info: Sync,

impl<O> !Sync for Boxed<O>

impl<T> Sync for OptionalTransport<T>where
    T: Sync,

impl Sync for ListenerId

impl<TUpgr, TErr> Sync for TransportEvent<TUpgr, TErr>where
    TErr: Sync,
    TUpgr: Sync,

impl<TErr> Sync for TransportError<TErr>where
    TErr: Sync,

impl<C, U> Sync for InboundUpgradeApply<C, U>where
    C: Sync,
    U: Sync,
    <U as InboundUpgrade<Negotiated<C>>>::Future: Sync,
    <U as UpgradeInfo>::Info: Sync,

impl<C, U> Sync for OutboundUpgradeApply<C, U>where
    C: Sync,
    U: Sync,
    <U as OutboundUpgrade<Negotiated<C>>>::Future: Sync,
    <U as UpgradeInfo>::Info: Sync,
    <<U as UpgradeInfo>::InfoIter as IntoIterator>::IntoIter: Sync,

impl<A, B> Sync for EitherUpgrade<A, B>where
    A: Sync,
    B: Sync,

impl<E> Sync for UpgradeError<E>where
    E: Sync,

impl<P, F> Sync for FromFnUpgrade<P, F>where
    F: Sync,
    P: Sync,

impl<U, F> Sync for MapInboundUpgrade<U, F>where
    F: Sync,
    U: Sync,

impl<U, F> Sync for MapOutboundUpgrade<U, F>where
    F: Sync,
    U: Sync,

impl<U, F> Sync for MapInboundUpgradeErr<U, F>where
    F: Sync,
    U: Sync,

impl<U, F> Sync for MapOutboundUpgradeErr<U, F>where
    F: Sync,
    U: Sync,

impl<T> Sync for OptionalUpgrade<T>where
    T: Sync,

impl<A, B> Sync for SelectUpgrade<A, B>where
    A: Sync,
    B: Sync,

impl<S> Sync for DeflateOutput<S>where
    S: Sync,

impl<T, C, P> Sync for GenDnsConfig<T, C, P>where
    T: Send,

impl<TErr> Sync for DnsErr<TErr>where
    TErr: Sync,

impl Sync for FloodsubRpc

impl Sync for Floodsub

impl Sync for Topic

impl Sync for ProtocolId

impl Sync for Config

impl Sync for Metrics

impl Sync for Inclusion

impl Sync for Churn

impl Sync for Penalty

impl<T> Sync for MaxCountSubscriptionFilter<T>where
    T: Sync,

impl<T, S> Sync for CombinedSubscriptionFilters<T, S>where
    S: Sync,
    T: Sync,

impl<T> Sync for CallbackSubscriptionFilter<T>where
    T: Sync,

impl<Key, Value> Sync for TimeCache<Key, Value>where
    Key: Sync,
    Value: Sync,

impl<'a, K, V> Sync for OccupiedEntry<'a, K, V>where
    K: Sync,
    V: Sync,

impl<'a, K, V> Sync for VacantEntry<'a, K, V>where
    K: Sync,
    V: Sync,

impl<'a, K, V> Sync for Entry<'a, K, V>where
    K: Sync,
    V: Sync,

impl<Key> Sync for DuplicateCache<Key>where
    Key: Sync,

impl Sync for TopicHash

impl<H> Sync for Topic<H>where
    H: Sync,

impl Sync for MessageId

impl !Sync for Identify

impl<T> Sync for KademliaHandlerProto<T>where
    T: Sync,

impl<TUserData> !Sync for KademliaHandler<TUserData>

impl<TUserData> Sync for KademliaHandlerEvent<TUserData>where
    TUserData: Sync,

impl<TUserData> Sync for KademliaHandlerIn<TUserData>where
    TUserData: Sync,

impl Sync for NodeStatus

impl<TKey, TVal> Sync for Node<TKey, TVal>where
    TKey: Sync,
    TVal: Sync,

impl<TKey> Sync for InsertResult<TKey>where
    TKey: Sync,

impl<TKey, TVal> Sync for AppliedPending<TKey, TVal>where
    TKey: Sync,
    TVal: Sync,

impl<'a, TPeerId, TVal> Sync for EntryRefView<'a, TPeerId, TVal>where
    TPeerId: Sync,
    TVal: Sync,

impl<'a, TKey, TVal> Sync for NodeRefView<'a, TKey, TVal>where
    TKey: Sync,
    TVal: Sync,

impl<TKey, TVal> Sync for EntryView<TKey, TVal>where
    TKey: Sync,
    TVal: Sync,

impl<'a, TPeerId, TVal> Sync for Entry<'a, TPeerId, TVal>where
    TPeerId: Sync,
    TVal: Sync,

impl<'a, TKey, TVal> Sync for PresentEntry<'a, TKey, TVal>where
    TKey: Sync,
    TVal: Sync,

impl<'a, TKey, TVal> Sync for PendingEntry<'a, TKey, TVal>where
    TKey: Sync,
    TVal: Sync,

impl<'a, TKey, TVal> Sync for AbsentEntry<'a, TKey, TVal>where
    TKey: Sync,
    TVal: Sync,

impl<T> Sync for Key<T>where
    T: Sync,

impl Sync for KeyBytes

impl Sync for Distance

impl<TKey, TVal> Sync for KBucketsTable<TKey, TVal>where
    TKey: Sync,
    TVal: Sync,

impl<'a, TKey, TVal> Sync for KBucketRef<'a, TKey, TVal>where
    TKey: Sync,
    TVal: Sync,

impl Sync for KadPeer

impl Sync for MemoryStore

impl Sync for Error

impl Sync for Key

impl Sync for Record

impl Sync for Addresses

impl<TStore> Sync for Kademlia<TStore>where
    TStore: Sync,

impl Sync for Quorum

impl Sync for PeerRecord

impl Sync for QueryResult

impl Sync for GetRecordOk

impl Sync for PutRecordOk

impl Sync for BootstrapOk

impl Sync for QueryInfo

impl<'a> Sync for QueryMut<'a>

impl<'a> Sync for QueryRef<'a>

impl Sync for QueryId

impl Sync for QueryStats

impl Sync for Mdns

impl Sync for MdnsEvent

impl Sync for MdnsConfig

impl Sync for MplexConfig

impl<C> Sync for Multiplex<C>where
    C: Send,

impl<C> Sync for Substream<C>where
    C: Send,

impl Sync for NoiseError

impl<C> Sync for RemoteIdentity<C>where
    C: Sync,

impl<T, C> !Sync for Handshake<T, C>

impl<T> Sync for NoiseOutput<T>where
    T: Sync,

impl Sync for X25519

impl Sync for X25519Spec

impl Sync for IK

impl Sync for IX

impl Sync for XX

impl<T> Sync for Keypair<T>where
    T: Sync,

impl<T> Sync for AuthenticKeypair<T>where
    T: Sync,

impl<T> Sync for SecretKey<T>where
    T: Sync,

impl<T> Sync for PublicKey<T>where
    T: Sync,

impl<P, C, R> Sync for NoiseConfig<P, C, R>where
    C: Sync,
    P: Sync,
    R: Sync,

impl<P, C, R> Sync for NoiseAuthenticated<P, C, R>where
    C: Sync,
    P: Sync,
    R: Sync,

impl Sync for Config

impl Sync for Success

impl !Sync for Failure

impl !Sync for Behaviour

impl !Sync for Event

impl<S> Sync for PlainTextOutput<S>where
    S: Sync,

impl Sync for Fingerprint

impl Sync for PnetConfig

impl<S> Sync for PnetOutput<S>where
    S: Sync,

impl Sync for PnetError

impl Sync for RelayError

impl Sync for Reservation

impl Sync for Event

impl Sync for Client

impl<Id> Sync for RateLimiter<Id>where
    Id: Sync,

impl !Sync for Config

impl Sync for Event

impl !Sync for Relay

impl Sync for CircuitId

impl Sync for RequestId

impl Sync for Namespace

impl Sync for Cookie

impl Sync for ErrorCode

impl !Sync for Behaviour

impl Sync for Event

impl !Sync for Behaviour

impl Sync for Config

impl Sync for Event

impl<TCodec> Sync for ResponseProtocol<TCodec>where
    TCodec: Sync,
    <TCodec as RequestResponseCodec>::Protocol: Sync,

impl<TCodec> Sync for RequestProtocol<TCodec>where
    TCodec: Sync,
    <TCodec as RequestResponseCodec>::Protocol: Sync,
    <TCodec as RequestResponseCodec>::Request: Sync,

impl<TRequest, TResponse, TChannelResponse> Sync for RequestResponseMessage<TRequest, TResponse, TChannelResponse>where
    TChannelResponse: Send,
    TRequest: Sync,
    TResponse: Sync,

impl<TRequest, TResponse, TChannelResponse> Sync for RequestResponseEvent<TRequest, TResponse, TChannelResponse>where
    TChannelResponse: Send,
    TRequest: Sync,
    TResponse: Sync,

impl<TResponse> Sync for ResponseChannel<TResponse>where
    TResponse: Send,

impl Sync for RequestId

impl<TCodec> !Sync for RequestResponse<TCodec>

impl<THandlerErr> Sync for ConnectionError<THandlerErr>where
    THandlerErr: Sync,

impl<TTransErr> Sync for PendingConnectionError<TTransErr>where
    TTransErr: Sync,

impl<T> Sync for SendWrapper<T>where
    T: Sync,

impl<TBehaviour> Sync for Toggle<TBehaviour>where
    TBehaviour: Sync,

impl<TInner> Sync for ToggleIntoConnectionHandler<TInner>where
    TInner: Sync,

impl<TInner> Sync for ToggleConnectionHandler<TInner>where
    TInner: Sync,

impl<TOutEvent, THandler, TInEvent> Sync for NetworkBehaviourAction<TOutEvent, THandler, TInEvent>where
    THandler: Sync,
    TInEvent: Sync,
    TOutEvent: Sync,

impl Sync for DialOpts

impl Sync for WithPeerId

impl<L, R> Sync for IntoEitherHandler<L, R>where
    L: Sync,
    R: Sync,

impl<TConnectionHandler, TNewIn, TMap> Sync for MapInEvent<TConnectionHandler, TNewIn, TMap>where
    TConnectionHandler: Sync,
    TMap: Sync,
    TNewIn: Sync,

impl<TConnectionHandler, TMap> Sync for MapOutEvent<TConnectionHandler, TMap>where
    TConnectionHandler: Sync,
    TMap: Sync,

impl<K, H> Sync for MultiHandler<K, H>where
    H: Sync,
    K: Sync,

impl<K, H> Sync for IntoMultiHandler<K, H>where
    H: Sync,
    K: Sync,

impl<H> Sync for IndexedProtoName<H>where
    H: Sync,

impl<K, I> Sync for Info<K, I>where
    I: Sync,
    K: Sync,

impl<K, H> Sync for Upgrade<K, H>where
    H: Sync,
    K: Sync,

impl<TInbound, TOutbound, TEvent> Sync for OneShotHandler<TInbound, TOutbound, TEvent>where
    TEvent: Sync,
    TInbound: Sync,
    TOutbound: Sync,
    <TOutbound as OutboundUpgradeSend>::Error: Sync,

impl<TProto1, TProto2> Sync for IntoConnectionHandlerSelect<TProto1, TProto2>where
    TProto1: Sync,
    TProto2: Sync,

impl<TProto1, TProto2> Sync for ConnectionHandlerSelect<TProto1, TProto2>where
    TProto1: Sync,
    TProto2: Sync,

impl<TUpgrade, TInfo> Sync for SubstreamProtocol<TUpgrade, TInfo>where
    TInfo: Sync,
    TUpgrade: Sync,

impl<TConnectionUpgrade, TOutboundOpenInfo, TCustom, TErr> Sync for ConnectionHandlerEvent<TConnectionUpgrade, TOutboundOpenInfo, TCustom, TErr>where
    TConnectionUpgrade: Sync,
    TCustom: Sync,
    TErr: Sync,
    TOutboundOpenInfo: Sync,

impl<TUpgrErr> Sync for ConnectionHandlerUpgrErr<TUpgrErr>where
    TUpgrErr: Sync,

impl Sync for KeepAlive

impl<TBehaviourOutEvent, THandlerErr> Sync for SwarmEvent<TBehaviourOutEvent, THandlerErr>where
    TBehaviourOutEvent: Sync,
    THandlerErr: Sync,

impl<TBehaviour> !Sync for Swarm<TBehaviour>

impl<'a> Sync for SwarmPollParameters<'a>

impl<TBehaviour> !Sync for SwarmBuilder<TBehaviour>

impl Sync for DialError

impl Sync for NetworkInfo

impl Sync for Tcp

impl<T> !Sync for GenTcpTransport<T>

impl<S> Sync for TcpListenerEvent<S>where
    S: Sync,

impl<T> !Sync for TcpListenStream<T>

impl !Sync for UdsConfig

impl !Sync for Transport

impl !Sync for Connection

impl !Sync for ListenEvent

impl Sync for Dial

impl Sync for Listen

impl Sync for Connection

impl Sync for JsErr

impl<E> Sync for Error<E>where
    E: Sync,

impl<T> Sync for WsConfig<T>where
    T: Send,

impl<T> !Sync for Connection<T>

impl Sync for Incoming

impl Sync for Data

impl Sync for Config

impl Sync for PrivateKey

impl Sync for Certificate

impl Sync for Builder

impl Sync for Error

impl<T> Sync for WsConfig<T>where
    T: Send,

impl<T> !Sync for BytesConnection<T>

impl<S> Sync for Yamux<S>where
    S: Send,

impl Sync for YamuxConfig

impl Sync for YamuxError

impl<T> !Sync for Incoming<T>

impl<T> !Sync for LocalIncoming<T>

impl Sync for __fsid_t

impl Sync for rocksdb_t

impl Sync for PublicKey

impl Sync for SecretKey

impl Sync for Signature

impl Sync for RecoveryId

impl Sync for Message

impl<D> Sync for SharedSecret<D>

impl Sync for Field

impl Sync for Affine

impl Sync for Jacobian

impl<'a> Sync for Decoder<'a>

impl Sync for Error

impl Sync for Scalar

impl !Sync for gz_header

impl !Sync for z_stream

impl<'a, K, V> Sync for Keys<'a, K, V>where
    K: Sync,
    V: Sync,

impl<'a, K, V> Sync for Values<'a, K, V>where
    K: Sync,
    V: Sync,

impl<'a, K, V, S = RandomState> !Sync for Entry<'a, K, V, S>

impl<'a, K, V, S = RandomState> !Sync for OccupiedEntry<'a, K, V, S>

impl<'a, K, V, S> Sync for VacantEntry<'a, K, V, S>where
    K: Sync,
    S: Sync,
    V: Sync,

impl<T, S> Sync for LinkedHashSet<T, S>where
    S: Sync,
    T: Sync,

impl<'a, K> Sync for Iter<'a, K>where
    K: Sync,

impl<K> Sync for IntoIter<K>where
    K: Sync,

impl<'a, T, S> Sync for Intersection<'a, T, S>where
    S: Sync,
    T: Sync,

impl<'a, T, S> Sync for Difference<'a, T, S>where
    S: Sync,
    T: Sync,

impl<'a, T, S> Sync for SymmetricDifference<'a, T, S>where
    S: Sync,
    T: Sync,

impl<'a, T, S> Sync for Union<'a, T, S>where
    S: Sync,
    T: Sync,

impl Sync for Error

impl<'a> Sync for RegressionData<'a>

impl<Storage> Sync for __BindgenBitfieldUnit<Storage>where
    Storage: Sync,

impl<T> Sync for __IncompleteArrayField<T>where
    T: Sync,

impl<T> Sync for __BindgenUnionField<T>where
    T: Sync,

impl Sync for f_owner_ex

impl Sync for flock

impl Sync for flock64

impl Sync for open_how

impl Sync for epoll_event

impl Sync for fscrypt_key

impl Sync for mount_attr

impl Sync for fsxattr

impl Sync for futex_waitv

impl !Sync for robust_list

impl Sync for in_addr

impl Sync for ip_mreq

impl Sync for ip_mreqn

impl Sync for ip_msfilter

impl !Sync for group_req

impl !Sync for group_filter

impl Sync for in_pktinfo

impl Sync for sockaddr_in

impl Sync for iphdr

impl Sync for ip_auth_hdr

impl Sync for ip_esp_hdr

impl Sync for ip_comp_hdr

impl Sync for in6_addr

impl Sync for ipv6_mreq

impl Sync for in6_pktinfo

impl Sync for ip6_mtuinfo

impl Sync for in6_ifreq

impl Sync for ipv6_rt_hdr

impl Sync for rt0_hdr

impl Sync for rt2_hdr

impl Sync for ipv6hdr

impl Sync for pollfd

impl !Sync for prctl_mm_map

impl Sync for timespec

impl Sync for timeval

impl Sync for itimerspec

impl Sync for itimerval

impl Sync for timezone

impl Sync for rusage

impl Sync for rlimit

impl Sync for rlimit64

impl Sync for clone_args

impl Sync for sigaction

impl !Sync for sigaltstack

impl !Sync for sigval

impl !Sync for __sifields

impl !Sync for siginfo

impl !Sync for sigevent

impl Sync for statx

impl Sync for tcphdr

impl Sync for tcp_info

impl !Sync for tcp_md5sig

impl Sync for termios

impl Sync for termios2

impl Sync for ktermios

impl Sync for winsize

impl Sync for termio

impl !Sync for iovec

impl Sync for sockaddr_un

impl Sync for old_utsname

impl Sync for new_utsname

impl Sync for uffd_msg

impl Sync for uffdio_api

impl Sync for uffdio_copy

impl !Sync for sockaddr

impl Sync for linger

impl Sync for stat

impl Sync for statfs

impl Sync for statfs64

impl Sync for user_desc

impl !Sync for msghdr

impl Sync for cmsghdr

impl Sync for ucred

impl !Sync for mmsghdr

impl<'a, R, T: ?Sized> Sync for RwLockReadGuard<'a, R, T>where
    R: Sync,
    T: Send + Sync,
    <R as RawRwLock>::GuardMarker: Sync,

impl<'a, R, T: ?Sized> Sync for RwLockWriteGuard<'a, R, T>where
    R: Sync,
    T: Send + Sync,
    <R as RawRwLock>::GuardMarker: Sync,

impl Sync for GuardSend

impl Sync for Error

impl<'k> Sync for Key<'k>

impl<S> Sync for AsMap<S>where
    S: Sync,

impl<S> Sync for AsList<S>where
    S: Sync,

impl<'v> !Sync for Value<'v>

impl Sync for Level

impl Sync for LevelFilter

impl<'a> !Sync for Record<'a>

impl<'a> !Sync for RecordBuilder<'a>

impl<'a> Sync for Metadata<'a>

impl<'a> Sync for MetadataBuilder<'a>

impl<K, V> Sync for IntoIter<K, V>where
    K: Sync,
    V: Sync,

impl<K, V, S> Sync for LruCache<K, V, S>where
    K: Sync,
    S: Sync,
    V: Sync,

impl<K, V> Sync for IntoIter<K, V>where
    K: Sync,
    V: Sync,

impl<'a, K, V> Sync for Iter<'a, K, V>where
    K: Sync,
    V: Sync,

impl<'a, K, V> Sync for IterMut<'a, K, V>where
    K: Sync,
    V: Sync,

impl Sync for LZ4Error

impl<R> !Sync for Decoder<R>

impl<W> !Sync for Encoder<W>

impl Sync for BlockSize

impl Sync for BlockMode

impl<S, A> Sync for Pattern<S, A>where
    A: Sync,

impl<'a, S, A> Sync for Matcher<'a, S, A>where
    A: Sync,
    S: Sync,

impl<'a> Sync for Memchr<'a>

impl<'a> Sync for Memchr2<'a>

impl<'a> Sync for Memchr3<'a>

impl Sync for Prefilter

impl<'h, 'n> Sync for FindIter<'h, 'n>

impl<'h, 'n> Sync for FindRevIter<'h, 'n>

impl<'n> Sync for Finder<'n>

impl<'n> Sync for FinderRev<'n>

impl Sync for Error

impl Sync for HugetlbSize

impl Sync for Memfd

impl Sync for FileSeal

impl Sync for Advice

impl Sync for MmapOptions

impl Sync for Mmap

impl Sync for MmapRaw

impl Sync for MmapMut

impl<T> Sync for MemCounter<T>where
    T: Sync,

impl<T> Sync for NoopTracker<T>where
    T: Sync,

impl<H, KF, T, M> Sync for MemoryDB<H, KF, T, M>where
    KF: Sync,
    M: Sync,
    T: Sync,

impl<H> Sync for HashKey<H>where
    H: Sync,

impl<H> Sync for PrefixedKey<H>where
    H: Sync,

impl<H> Sync for LegacyPrefixedKey<H>

impl<K, V> Sync for MemoryLruCache<K, V>where
    K: Sync,
    V: Sync,

impl Sync for Words

impl Sync for Pages

impl Sync for Words

impl Sync for Pages

impl Sync for Bytes

impl Sync for Transcript

impl Sync for Config

impl Sync for TracesIn

impl Sync for Span

impl Sync for StartTime

impl<'a> Sync for Log<'a>

impl Sync for TracesOut

impl Sync for TDEFLFlush

impl Sync for TDEFLStatus

impl<'a> !Sync for CallbackFunc<'a>

impl Sync for MinReset

impl Sync for ZeroReset

impl Sync for FullReset

impl Sync for TINFLStatus

impl Sync for MZFlush

impl Sync for MZStatus

impl Sync for MZError

impl Sync for DataFormat

impl Sync for Interest

impl Sync for Poll

impl Sync for Registry

impl<'a> Sync for SourceFd<'a>

impl Sync for SocketAddr

impl Sync for Sender

impl Sync for Receiver

impl Sync for Token

impl Sync for Waker

impl Sync for Event

impl Sync for Events

impl<'a> Sync for Iter<'a>

impl Sync for TcpListener

impl Sync for TcpStream

impl Sync for UdpSocket

impl Sync for UnixStream

impl<'a> Sync for Protocol<'a>

impl<'a> Sync for Onion3Addr<'a>

impl Sync for Error

impl Sync for FromUrlErr

impl Sync for Multiaddr

impl<'a> Sync for Iter<'a>

impl Sync for Base

impl Sync for Error

impl Sync for Error

impl<const S: usize> Sync for Blake2bHasher<S>

impl<const S: usize> Sync for Blake2sHasher<S>

impl<const S: usize> Sync for Blake3Hasher<S>

impl Sync for Sha2_256

impl Sync for Sha2_512

impl Sync for Sha3_224

impl Sync for Sha3_256

impl Sync for Sha3_384

impl Sync for Sha3_512

impl Sync for Keccak224

impl Sync for Keccak256

impl Sync for Keccak384

impl Sync for Keccak512

impl<const S: usize> Sync for IdentityHasher<S>

impl<const S: usize> Sync for Multihash<S>

impl Sync for Code

impl<R, N> Sync for ListenerSelectFuture<R, N>where
    N: Sync,
    R: Sync,

impl<TInner> Sync for Negotiated<TInner>where
    TInner: Sync,

impl<TInner> Sync for NegotiatedComplete<TInner>where
    TInner: Sync,

impl Sync for Version

impl<T> Sync for X<T>where
    T: Sync,

impl<T> Sync for XY<T>where
    T: Sync,

impl<T> Sync for XYZ<T>where
    T: Sync,

impl<T> Sync for XYZW<T>where
    T: Sync,

impl<T> Sync for XYZWA<T>where
    T: Sync,

impl<T> Sync for XYZWAB<T>where
    T: Sync,

impl<T> Sync for IJKW<T>where
    T: Sync,

impl<T> Sync for M2x2<T>where
    T: Sync,

impl<T> Sync for M2x3<T>where
    T: Sync,

impl<T> Sync for M2x4<T>where
    T: Sync,

impl<T> Sync for M2x5<T>where
    T: Sync,

impl<T> Sync for M2x6<T>where
    T: Sync,

impl<T> Sync for M3x2<T>where
    T: Sync,

impl<T> Sync for M3x3<T>where
    T: Sync,

impl<T> Sync for M3x4<T>where
    T: Sync,

impl<T> Sync for M3x5<T>where
    T: Sync,

impl<T> Sync for M3x6<T>where
    T: Sync,

impl<T> Sync for M4x2<T>where
    T: Sync,

impl<T> Sync for M4x3<T>where
    T: Sync,

impl<T> Sync for M4x4<T>where
    T: Sync,

impl<T> Sync for M4x5<T>where
    T: Sync,

impl<T> Sync for M4x6<T>where
    T: Sync,

impl<T> Sync for M5x2<T>where
    T: Sync,

impl<T> Sync for M5x3<T>where
    T: Sync,

impl<T> Sync for M5x4<T>where
    T: Sync,

impl<T> Sync for M5x5<T>where
    T: Sync,

impl<T> Sync for M5x6<T>where
    T: Sync,

impl<T> Sync for M6x2<T>where
    T: Sync,

impl<T> Sync for M6x3<T>where
    T: Sync,

impl<T> Sync for M6x4<T>where
    T: Sync,

impl<T> Sync for M6x5<T>where
    T: Sync,

impl<T> Sync for M6x6<T>where
    T: Sync,

impl Sync for Dynamic

impl<const R: usize> Sync for Const<R>

impl<'a, T, R, C, S> !Sync for MatrixIter<'a, T, R, C, S>

impl<'a, T, R, C, S> !Sync for MatrixIterMut<'a, T, R, C, S>

impl<'a, T, R, C, S> Sync for RowIter<'a, T, R, C, S>where
    S: Sync,
    T: Sync,

impl<'a, T, R, C, S> !Sync for RowIterMut<'a, T, R, C, S>

impl<'a, T, R, C, S> Sync for ColumnIter<'a, T, R, C, S>where
    S: Sync,
    T: Sync,

impl<'a, T, R, C, S> !Sync for ColumnIterMut<'a, T, R, C, S>

impl<T, const R: usize, const C: usize> Sync for ArrayStorage<T, R, C>where
    T: Sync,

impl<T, R, C, S> Sync for Matrix<T, R, C, S>where
    C: Sync,
    R: Sync,
    S: Sync,
    T: Sync,

impl Sync for LpNorm

impl Sync for UniformNorm

impl<T> Sync for Unit<T>where
    T: Sync,

impl<T, R, C> Sync for VecStorage<T, R, C>where
    T: Sync,

impl<T, const D: usize> Sync for Point<T, D>where
    T: Sync,

impl<T, const D: usize> Sync for Rotation<T, D>where
    T: Sync,

impl<T> Sync for Quaternion<T>where
    T: Sync,

impl<T> Sync for DualQuaternion<T>where
    T: Sync,

impl<T, const D: usize> Sync for Translation<T, D>where
    T: Sync,

impl<T, R, const D: usize> Sync for Isometry<T, R, D>where
    R: Sync,
    T: Sync,

impl<T, R, const D: usize> Sync for Similarity<T, R, D>where
    R: Sync,
    T: Sync,

impl Sync for TGeneral

impl Sync for TProjective

impl Sync for TAffine

impl<T, C, const D: usize> !Sync for Transform<T, C, D>

impl<T, D, S> Sync for Reflection<T, D, S>where
    S: Sync,
    T: Sync,

impl<T> Sync for Orthographic3<T>

impl<T> Sync for Perspective3<T>where
    T: Sync,

impl<T, R, C> !Sync for Bidiagonal<T, R, C>

impl<T, D> !Sync for Cholesky<T, D>

impl<T, R, C> !Sync for ColPivQR<T, R, C>

impl<T, R, C> !Sync for FullPivLU<T, R, C>

impl<T> Sync for GivensRotation<T>

impl<T, D> !Sync for Hessenberg<T, D>

impl<T, R, C> !Sync for LU<T, R, C>

impl<D> !Sync for PermutationSequence<D>

impl<T, R, C> !Sync for QR<T, R, C>

impl<T, D> !Sync for Schur<T, D>

impl<T, R, C> !Sync for SVD<T, R, C>

impl<T, D> !Sync for SymmetricEigen<T, D>

impl<T, D> !Sync for SymmetricTridiagonal<T, D>

impl<T, D> !Sync for UDU<T, D>

impl Sync for Name

impl<'a> !Sync for Generator<'a>

impl Sync for WyRand

impl<T> Sync for ErrorBuffer<T>where
    T: Sync,

impl<T> Sync for NetlinkBuffer<T>where
    T: Sync,

impl<I> Sync for NetlinkPayload<I>where
    I: Sync,

impl<I> Sync for NetlinkMessage<I>where
    I: Sync,

impl<T> Sync for AddressMessageBuffer<T>where
    T: Sync,

impl Sync for CacheInfo

impl<T> Sync for CacheInfoBuffer<T>where
    T: Sync,

impl Sync for Nla

impl<T> Sync for LinkMessageBuffer<T>where
    T: Sync,

impl Sync for LinkHeader

impl Sync for LinkMessage

impl<T> Sync for InetDevConfBuffer<T>where
    T: Sync,

impl Sync for InetDevConf

impl Sync for Inet

impl<T> Sync for Inet6CacheInfoBuffer<T>where
    T: Sync,

impl<T> Sync for Inet6DevConfBuffer<T>where
    T: Sync,

impl Sync for Icmp6Stats

impl<T> Sync for Icmp6StatsBuffer<T>where
    T: Sync,

impl<T> Sync for Inet6StatsBuffer<T>where
    T: Sync,

impl Sync for Inet6Stats

impl Sync for Inet6

impl Sync for AfSpecInet

impl Sync for Info

impl Sync for InfoData

impl Sync for InfoKind

impl Sync for InfoVxlan

impl Sync for InfoVlan

impl Sync for InfoBridge

impl Sync for InfoIpoib

impl Sync for VethInfo

impl Sync for InfoIpVlan

impl Sync for InfoVrf

impl Sync for InfoMacVlan

impl Sync for InfoMacVtap

impl Sync for Prop

impl<T> Sync for MapBuffer<T>where
    T: Sync,

impl Sync for Map

impl Sync for Stats

impl<T> Sync for StatsBuffer<T>where
    T: Sync,

impl<T> Sync for Stats64Buffer<T>where
    T: Sync,

impl Sync for Stats64

impl Sync for State

impl Sync for Nla

impl<T> Sync for NeighbourMessageBuffer<T>where
    T: Sync,

impl Sync for CacheInfo

impl<T> Sync for CacheInfoBuffer<T>where
    T: Sync,

impl Sync for Nla

impl<T> Sync for NeighbourTableMessageBuffer<T>where
    T: Sync,

impl Sync for Config

impl<T> Sync for ConfigBuffer<T>where
    T: Sync,

impl Sync for Stats

impl<T> Sync for StatsBuffer<T>where
    T: Sync,

impl Sync for Nla

impl<T> Sync for NsidMessageBuffer<T>where
    T: Sync,

impl Sync for NsidHeader

impl Sync for NsidMessage

impl Sync for Nla

impl<T> Sync for RouteMessageBuffer<T>where
    T: Sync,

impl Sync for RouteFlags

impl Sync for RouteHeader

impl Sync for CacheInfo

impl<T> Sync for CacheInfoBuffer<T>where
    T: Sync,

impl Sync for Metrics

impl Sync for MfcStats

impl<T> Sync for MfcStatsBuffer<T>where
    T: Sync,

impl<T> Sync for NextHopBuffer<T>where
    T: Sync,

impl Sync for NextHop

impl Sync for Nla

impl<T> Sync for RuleMessageBuffer<T>where
    T: Sync,

impl Sync for RuleFlags

impl Sync for RuleHeader

impl Sync for RuleMessage

impl Sync for Nla

impl<T> Sync for TcMessageBuffer<T>where
    T: Sync,

impl Sync for TcMessage

impl Sync for TcHeader

impl Sync for Stats

impl<T> Sync for StatsBuffer<T>where
    T: Sync,

impl Sync for StatsQueue

impl<T> Sync for StatsQueueBuffer<T>where
    T: Sync,

impl Sync for StatsBasic

impl<T> Sync for StatsBasicBuffer<T>where
    T: Sync,

impl Sync for TcOpt

impl Sync for Nla

impl Sync for Sel

impl<T> Sync for SelBuffer<T>where
    T: Sync,

impl Sync for Key

impl<T> Sync for KeyBuffer<T>where
    T: Sync,

impl Sync for Nla

impl Sync for TcMirred

impl<T> Sync for TcMirredBuffer<T>where
    T: Sync,

impl Sync for Action

impl Sync for ActNla

impl Sync for ActOpt

impl Sync for TcGen

impl<T> Sync for TcGenBuffer<T>where
    T: Sync,

impl Sync for Nla

impl Sync for Stats2

impl<T> Sync for RtnlMessageBuffer<T>where
    T: Sync,

impl Sync for RtnlMessage

impl Sync for EncodeError

impl Sync for DecodeError

impl<T> Sync for NlaBuffer<T>where
    T: Sync,

impl Sync for DefaultNla

impl<T> Sync for NlasIterator<T>where
    T: Sync,

impl<T, S, C> Sync for NetlinkFramed<T, S, C>where
    S: Sync,

impl<T, S, C> Sync for Connection<T, S, C>where
    S: Sync,
    T: Send + Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for ConnectionHandle<T>where
    T: Send,

impl Sync for Socket

impl Sync for SocketAddr

impl<'a, 'b, S> Sync for PollSend<'a, 'b, S>where
    S: Sync,

impl<'a, 'b, S> Sync for PollSendTo<'a, 'b, S>where
    S: Sync,

impl<'a, 'b, S, B> Sync for PollRecv<'a, 'b, S, B>where
    B: Sync,
    S: Sync,

impl<'a, 'b, S, B> Sync for PollRecvFrom<'a, 'b, S, B>where
    B: Sync,
    S: Sync,

impl<'a, S> Sync for PollRecvFromFull<'a, S>where
    S: Sync,

impl Sync for SmolSocket

impl Sync for Errno

impl Sync for AtFlags

impl Sync for OFlag

impl Sync for RenameFlags

impl Sync for SealFlag

impl Sync for FdFlag

impl<'a> Sync for FcntlArg<'a>

impl Sync for FlockArg

impl Sync for MsFlags

impl Sync for MntFlags

impl Sync for CloneFlags

impl Sync for CpuSet

impl !Sync for SigEvent

impl Sync for Signal

impl Sync for SaFlags

impl Sync for SigmaskHow

impl Sync for SigSet

impl<'a> Sync for SigSetIter<'a>

impl Sync for SigHandler

impl Sync for SigAction

impl Sync for SigevNotify

impl Sync for SfdFlags

impl Sync for SignalFd

impl Sync for SFlag

impl Sync for Mode

impl Sync for Statfs

impl Sync for FsType

impl Sync for FsFlags

impl Sync for Statvfs

impl Sync for SysInfo

impl Sync for TimeSpec

impl Sync for TimeVal

impl Sync for RemoteIoVec

impl Sync for WaitPidFlag

impl Sync for WaitStatus

impl Sync for Id

impl Sync for Pid

impl Sync for ForkResult

impl Sync for Whence

impl Sync for LinkatFlags

impl Sync for AccessFlags

impl<T> Sync for NoHashHasher<T>where
    T: Sync,

impl Sync for Sign

impl Sync for BigInt

impl Sync for BigUint

impl<T> Sync for Complex<T>where
    T: Sync,

impl<E> Sync for ParseComplexError<E>where
    E: Sync,

impl Sync for Buffer

impl Sync for Error

impl Sync for ErrorKind

impl Sync for Grouping

impl Sync for Locale

impl<'a> Sync for DecimalStr<'a>

impl<'a> Sync for InfinityStr<'a>

impl<'a> Sync for MinusSignStr<'a>

impl<'a> Sync for NanStr<'a>

impl<'a> Sync for PlusSignStr<'a>

impl<'a> Sync for SeparatorStr<'a>

impl<A> Sync for ExtendedGcd<A>where
    A: Sync,

impl<T> Sync for IterBinomial<T>where
    T: Sync,

impl<T> Sync for Ratio<T>where
    T: Sync,

impl Sync for AddressSize

impl Sync for SectionKind

impl Sync for ComdatKind

impl Sync for SymbolKind

impl Sync for SymbolScope

impl Sync for FileFlags

impl<Section> Sync for SymbolFlags<Section>where
    Section: Sync,

impl Sync for Endianness

impl Sync for BigEndian

impl<E> Sync for U16Bytes<E>where
    E: Sync,

impl<E> Sync for U32Bytes<E>where
    E: Sync,

impl<E> Sync for U64Bytes<E>where
    E: Sync,

impl<E> Sync for I16Bytes<E>where
    E: Sync,

impl<E> Sync for I32Bytes<E>where
    E: Sync,

impl<E> Sync for I64Bytes<E>where
    E: Sync,

impl<'data> Sync for Bytes<'data>

impl<'data, R> Sync for StringTable<'data, R>where
    R: Sync,

impl<'data, R> Sync for File<'data, R>where
    R: Sync,

impl<'data, 'file, R> Sync for SegmentIterator<'data, 'file, R>where
    R: Sync,

impl<'data, 'file, R> Sync for Segment<'data, 'file, R>where
    R: Sync,

impl<'data, 'file, R> Sync for SectionIterator<'data, 'file, R>where
    R: Sync,

impl<'data, 'file, R> Sync for Section<'data, 'file, R>where
    R: Sync,

impl<'data, 'file, R> Sync for ComdatIterator<'data, 'file, R>where
    R: Sync,

impl<'data, 'file, R> Sync for Comdat<'data, 'file, R>where
    R: Sync,

impl<'data, 'file, R> Sync for ComdatSectionIterator<'data, 'file, R>where
    R: Sync,

impl<'data, 'file, R> Sync for SymbolTable<'data, 'file, R>where
    R: Sync,

impl<'data, 'file, R> Sync for SymbolIterator<'data, 'file, R>where
    R: Sync,

impl<'data, 'file, R> Sync for Symbol<'data, 'file, R>where
    R: Sync,

impl<'data, 'file, R> Sync for DynamicRelocationIterator<'data, 'file, R>where
    R: Sync,

impl<'data, 'file, R> Sync for SectionRelocationIterator<'data, 'file, R>where
    R: Sync,

impl Sync for ArchiveKind

impl<'data, R> Sync for ArchiveFile<'data, R>where
    R: Sync,

impl<'data, R> Sync for ArchiveMemberIterator<'data, R>where
    R: Sync,

impl<'data> Sync for ArchiveMember<'data>

impl<'data, R> Sync for CoffFile<'data, R>where
    R: Sync,

impl<'data> Sync for SectionTable<'data>

impl<'data, 'file, R> Sync for CoffSegmentIterator<'data, 'file, R>where
    R: Sync,

impl<'data, 'file, R> Sync for CoffSegment<'data, 'file, R>where
    R: Sync,

impl<'data, 'file, R> Sync for CoffSectionIterator<'data, 'file, R>where
    R: Sync,

impl<'data, 'file, R> Sync for CoffSection<'data, 'file, R>where
    R: Sync,

impl<'data, R> Sync for SymbolTable<'data, R>where
    R: Sync,

impl<'data, 'table, R> Sync for SymbolIterator<'data, 'table, R>where
    R: Sync,

impl<'data, 'file, R> Sync for CoffSymbolTable<'data, 'file, R>where
    R: Sync,

impl<'data, 'file, R> Sync for CoffSymbolIterator<'data, 'file, R>where
    R: Sync,

impl<'data, 'file, R> Sync for CoffSymbol<'data, 'file, R>where
    R: Sync,

impl<'data, 'file, R> Sync for CoffRelocationIterator<'data, 'file, R>where
    R: Sync,

impl<'data, 'file, R> Sync for CoffComdatIterator<'data, 'file, R>where
    R: Sync,

impl<'data, 'file, R> Sync for CoffComdat<'data, 'file, R>where
    R: Sync,

impl<'data, 'file, R> Sync for CoffComdatSectionIterator<'data, 'file, R>where
    R: Sync,

impl<'data, Elf, R> Sync for ElfFile<'data, 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> Sync 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> Sync 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> Sync for SectionTable<'data, Elf, R>where
    R: Sync,
    <Elf as FileHeader>::SectionHeader: Sync,

impl<'data, 'file, Elf, R> Sync 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> Sync 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> Sync for SymbolTable<'data, Elf, R>where
    R: Sync,
    <Elf as FileHeader>::Sym: Sync,

impl<'data, 'file, Elf, R> Sync for ElfSymbolTable<'data, 'file, Elf, R>where
    R: Sync,
    <Elf as FileHeader>::Endian: Sync,
    <Elf as FileHeader>::Sym: Sync,

impl<'data, 'file, Elf, R> Sync for ElfSymbolIterator<'data, 'file, Elf, R>where
    R: Sync,
    <Elf as FileHeader>::Endian: Sync,
    <Elf as FileHeader>::Sym: Sync,

impl<'data, 'file, Elf, R> Sync for ElfSymbol<'data, 'file, Elf, R>where
    R: Sync,
    <Elf as FileHeader>::Endian: Sync,
    <Elf as FileHeader>::Sym: Sync,

impl<'data, 'file, Elf, R> Sync 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> Sync 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> Sync 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> Sync 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> Sync 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> Sync for NoteIterator<'data, Elf>where
    <Elf as FileHeader>::Endian: Sync,

impl<'data, Elf> Sync for Note<'data, Elf>where
    <Elf as FileHeader>::NoteHeader: Sync,

impl<'data, Elf> Sync for HashTable<'data, Elf>where
    <Elf as FileHeader>::Endian: Sync,

impl<'data, Elf> Sync for GnuHashTable<'data, Elf>where
    <Elf as FileHeader>::Endian: Sync,

impl<'data> Sync for Version<'data>

impl<'data, Elf> Sync for VersionTable<'data, Elf>where
    <Elf as FileHeader>::Endian: Sync,

impl<'data, Elf> Sync for VerdefIterator<'data, Elf>where
    <Elf as FileHeader>::Endian: Sync,

impl<'data, Elf> Sync for VerdauxIterator<'data, Elf>where
    <Elf as FileHeader>::Endian: Sync,

impl<'data, Elf> Sync for VerneedIterator<'data, Elf>where
    <Elf as FileHeader>::Endian: Sync,

impl<'data, Elf> Sync for VernauxIterator<'data, Elf>where
    <Elf as FileHeader>::Endian: Sync,

impl<'data, E, R> Sync for DyldCache<'data, E, R>where
    E: Sync,
    R: Sync,

impl<'data, E, R> Sync for DyldSubCache<'data, E, R>where
    E: Sync,
    R: Sync,

impl<'data, 'cache, E, R> Sync for DyldCacheImageIterator<'data, 'cache, E, R>where
    E: Sync,
    R: Sync,

impl<'data, 'cache, E, R> Sync for DyldCacheImage<'data, 'cache, E, R>where
    E: Sync,
    R: Sync,

impl<'data, Mach, R> Sync for MachOFile<'data, 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> Sync 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> Sync 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> Sync 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> Sync for LoadCommandIterator<'data, E>where
    E: Sync,

impl<'data, E> Sync for LoadCommandData<'data, E>where
    E: Sync,

impl<'data, E> Sync for LoadCommandVariant<'data, E>where
    E: Sync,

impl<'data, 'file, Mach, R> Sync 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> Sync 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> Sync 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> Sync 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> Sync for SymbolTable<'data, Mach, R>where
    R: Sync,
    <Mach as MachHeader>::Nlist: Sync,

impl<'data, 'file, Mach, R> Sync 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> Sync 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> Sync 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> Sync 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> Sync for PeFile<'data, Pe, R>where
    Pe: Sync,
    R: Sync,

impl<'data, 'file, Pe, R> Sync for PeComdatIterator<'data, 'file, Pe, R>where
    Pe: Sync,
    R: Sync,

impl<'data, 'file, Pe, R> Sync for PeComdat<'data, 'file, Pe, R>where
    Pe: Sync,
    R: Sync,

impl<'data, 'file, Pe, R> Sync for PeComdatSectionIterator<'data, 'file, Pe, R>where
    Pe: Sync,
    R: Sync,

impl<'data, 'file, Pe, R> Sync for PeSegmentIterator<'data, 'file, Pe, R>where
    Pe: Sync,
    R: Sync,

impl<'data, 'file, Pe, R> Sync for PeSegment<'data, 'file, Pe, R>where
    Pe: Sync,
    R: Sync,

impl<'data, 'file, Pe, R> Sync for PeSectionIterator<'data, 'file, Pe, R>where
    Pe: Sync,
    R: Sync,

impl<'data, 'file, Pe, R> Sync for PeSection<'data, 'file, Pe, R>where
    Pe: Sync,
    R: Sync,

impl<'data, 'file, R> Sync for PeRelocationIterator<'data, 'file, R>where
    R: Sync,

impl<'data> Sync for DataDirectories<'data>

impl<'data> Sync for ExportTarget<'data>

impl<'data> Sync for Export<'data>

impl<'data> Sync for ExportTable<'data>

impl<'data> Sync for ImportTable<'data>

impl<'data> Sync for ImportDescriptorIterator<'data>

impl<'data> Sync for ImportThunkList<'data>

impl<'data> Sync for Import<'data>

impl<'data> Sync for RelocationBlockIterator<'data>

impl<'data> Sync for RelocationIterator<'data>

impl Sync for Relocation

impl<'data> Sync for ResourceDirectory<'data>

impl<'data> Sync for ResourceDirectoryTable<'data>

impl<'data> Sync for ResourceDirectoryEntryData<'data>

impl<'data> Sync for RichHeaderInfo<'data>

impl Sync for Error

impl Sync for FileKind

impl Sync for ObjectKind

impl Sync for SymbolIndex

impl<T> Sync for SymbolMap<T>where
    T: Sync,

impl<'data> Sync for SymbolMapName<'data>

impl<'data> Sync for ObjectMap<'data>

impl<'data> Sync for ObjectMapEntry<'data>

impl<'data> Sync for Import<'data>

impl<'data> Sync for Export<'data>

impl<'data> Sync for CodeView<'data>

impl Sync for Relocation

impl<'data> Sync for CompressedData<'data>

impl Sync for Header

impl<E> Sync for FileHeader32<E>where
    E: Sync,

impl<E> Sync for FileHeader64<E>where
    E: Sync,

impl Sync for Ident

impl<E> Sync for SectionHeader32<E>where
    E: Sync,

impl<E> Sync for SectionHeader64<E>where
    E: Sync,

impl<E> Sync for CompressionHeader32<E>where
    E: Sync,

impl<E> Sync for CompressionHeader64<E>where
    E: Sync,

impl<E> Sync for Sym32<E>where
    E: Sync,

impl<E> Sync for Sym64<E>where
    E: Sync,

impl<E> Sync for Syminfo32<E>where
    E: Sync,

impl<E> Sync for Syminfo64<E>where
    E: Sync,

impl<E> Sync for Rel32<E>where
    E: Sync,

impl<E> Sync for Rela32<E>where
    E: Sync,

impl<E> Sync for Rel64<E>where
    E: Sync,

impl<E> Sync for Rela64<E>where
    E: Sync,

impl<E> Sync for ProgramHeader32<E>where
    E: Sync,

impl<E> Sync for ProgramHeader64<E>where
    E: Sync,

impl<E> Sync for Dyn32<E>where
    E: Sync,

impl<E> Sync for Dyn64<E>where
    E: Sync,

impl<E> Sync for Versym<E>where
    E: Sync,

impl<E> Sync for Verdef<E>where
    E: Sync,

impl<E> Sync for Verdaux<E>where
    E: Sync,

impl<E> Sync for Verneed<E>where
    E: Sync,

impl<E> Sync for Vernaux<E>where
    E: Sync,

impl<E> Sync for NoteHeader32<E>where
    E: Sync,

impl<E> Sync for NoteHeader64<E>where
    E: Sync,

impl<E> Sync for HashHeader<E>where
    E: Sync,

impl<E> Sync for GnuHashHeader<E>where
    E: Sync,

impl<E> Sync for DyldCacheHeader<E>where
    E: Sync,

impl<E> Sync for DyldCacheMappingInfo<E>where
    E: Sync,

impl<E> Sync for DyldCacheImageInfo<E>where
    E: Sync,

impl<E> Sync for DyldSubCacheInfo<E>where
    E: Sync,

impl Sync for FatHeader

impl Sync for FatArch32

impl Sync for FatArch64

impl<E> Sync for MachHeader32<E>where
    E: Sync,

impl<E> Sync for MachHeader64<E>where
    E: Sync,

impl<E> Sync for LoadCommand<E>where
    E: Sync,

impl<E> Sync for LcStr<E>where
    E: Sync,

impl<E> Sync for SegmentCommand32<E>where
    E: Sync,

impl<E> Sync for SegmentCommand64<E>where
    E: Sync,

impl<E> Sync for Section32<E>where
    E: Sync,

impl<E> Sync for Section64<E>where
    E: Sync,

impl<E> Sync for Fvmlib<E>where
    E: Sync,

impl<E> Sync for FvmlibCommand<E>where
    E: Sync,

impl<E> Sync for Dylib<E>where
    E: Sync,

impl<E> Sync for DylibCommand<E>where
    E: Sync,

impl<E> Sync for SubFrameworkCommand<E>where
    E: Sync,

impl<E> Sync for SubClientCommand<E>where
    E: Sync,

impl<E> Sync for SubUmbrellaCommand<E>where
    E: Sync,

impl<E> Sync for SubLibraryCommand<E>where
    E: Sync,

impl<E> Sync for PreboundDylibCommand<E>where
    E: Sync,

impl<E> Sync for DylinkerCommand<E>where
    E: Sync,

impl<E> Sync for ThreadCommand<E>where
    E: Sync,

impl<E> Sync for RoutinesCommand32<E>where
    E: Sync,

impl<E> Sync for RoutinesCommand64<E>where
    E: Sync,

impl<E> Sync for SymtabCommand<E>where
    E: Sync,

impl<E> Sync for DysymtabCommand<E>where
    E: Sync,

impl<E> Sync for DylibTableOfContents<E>where
    E: Sync,

impl<E> Sync for DylibModule32<E>where
    E: Sync,

impl<E> Sync for DylibModule64<E>where
    E: Sync,

impl<E> Sync for DylibReference<E>where
    E: Sync,

impl<E> Sync for TwolevelHintsCommand<E>where
    E: Sync,

impl<E> Sync for TwolevelHint<E>where
    E: Sync,

impl<E> Sync for PrebindCksumCommand<E>where
    E: Sync,

impl<E> Sync for UuidCommand<E>where
    E: Sync,

impl<E> Sync for RpathCommand<E>where
    E: Sync,

impl<E> Sync for LinkeditDataCommand<E>where
    E: Sync,

impl<E> Sync for FilesetEntryCommand<E>where
    E: Sync,

impl<E> Sync for EncryptionInfoCommand32<E>where
    E: Sync,

impl<E> Sync for EncryptionInfoCommand64<E>where
    E: Sync,

impl<E> Sync for VersionMinCommand<E>where
    E: Sync,

impl<E> Sync for BuildVersionCommand<E>where
    E: Sync,

impl<E> Sync for BuildToolVersion<E>where
    E: Sync,

impl<E> Sync for DyldInfoCommand<E>where
    E: Sync,

impl<E> Sync for LinkerOptionCommand<E>where
    E: Sync,

impl<E> Sync for SymsegCommand<E>where
    E: Sync,

impl<E> Sync for IdentCommand<E>where
    E: Sync,

impl<E> Sync for FvmfileCommand<E>where
    E: Sync,

impl<E> Sync for EntryPointCommand<E>where
    E: Sync,

impl<E> Sync for SourceVersionCommand<E>where
    E: Sync,

impl<E> Sync for DataInCodeEntry<E>where
    E: Sync,

impl<E> Sync for NoteCommand<E>where
    E: Sync,

impl<E> Sync for Nlist32<E>where
    E: Sync,

impl<E> Sync for Nlist64<E>where
    E: Sync,

impl<E> Sync for Relocation<E>where
    E: Sync,

impl Sync for Guid

impl Sync for ImageSymbol

impl<T> !Sync for OnceCell<T>

impl<T, F = fn() -> T> !Sync for Lazy<T, F>

impl<T> Sync for OnceCell<T>where
    T: Send + Sync,

impl Sync for OnceBool

impl Sync for ProbeResult

impl !Sync for ToOrchestra

impl<T> Sync for MessagePacket<T>where
    T: Sync,

impl<E> !Sync for SpawnedSubsystem<E>

impl<Message, Signal> Sync for SubsystemInstance<Message, Signal>where
    Message: Send,
    Signal: Send,

impl<Message, Signal> Sync for FromOrchestra<Message, Signal>where
    Message: Sync,
    Signal: Sync,

impl<F> Sync for Timeout<F>where
    F: Sync,

impl<T> Sync for OrderedFloat<T>where
    T: Sync,

impl<T> Sync for NotNan<T>where
    T: Sync,

impl Sync for FloatIsNan

impl<E> Sync for ParseNotNanError<E>where
    E: Sync,

impl<T, GetCurrencyId> Sync for PositiveImbalance<T, GetCurrencyId>where
    GetCurrencyId: Sync,

impl<T, GetCurrencyId> Sync for NegativeImbalance<T, GetCurrencyId>where
    GetCurrencyId: Sync,

impl<AccountId, TestKey, A, B> Sync for Combiner<AccountId, TestKey, A, B>where
    A: Sync,
    AccountId: Sync,
    B: Sync,
    TestKey: Sync,

impl<AccountId, T, C, B, GetCurrencyId> Sync for Mapper<AccountId, T, C, B, GetCurrencyId>where
    AccountId: Sync,
    B: Sync,
    C: Sync,
    GetCurrencyId: Sync,
    T: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,

impl<T> Sync for GenesisConfig<T>

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,
    <<T as Config>::Lookup as StaticLookup>::Source: Sync,

impl<T, GetAccountId> Sync for TransferDust<T, GetAccountId>where
    GetAccountId: Sync,
    T: Sync,

impl<T> Sync for BurnDust<T>where
    T: Sync,

impl<Balance> Sync for BalanceLock<Balance>where
    Balance: Sync,

impl<ReserveIdentifier, Balance> Sync for ReserveData<ReserveIdentifier, Balance>where
    Balance: Sync,
    ReserveIdentifier: Sync,

impl<Balance> Sync for AccountData<Balance>where
    Balance: Sync,

impl<T, GetCurrencyId> Sync for CurrencyAdapter<T, GetCurrencyId>where
    GetCurrencyId: Sync,
    T: Sync,

impl<Balance, CustomMetadata> Sync for AssetMetadata<Balance, CustomMetadata>where
    Balance: Sync,

impl<AccountId, Balance, BlockNumber> Sync for AuctionInfo<AccountId, Balance, BlockNumber>where
    AccountId: Sync,
    Balance: Sync,
    BlockNumber: Sync,

impl<BlockNumber> Sync for OnNewBidResult<BlockNumber>where
    BlockNumber: Sync,

impl<CurrencyId, Source> Sync for DefaultPriceProvider<CurrencyId, Source>where
    CurrencyId: Sync,
    Source: Sync,

impl<Value> Sync for Change<Value>where
    Value: Sync,

impl<Value, Moment> Sync for TimestampedValue<Value, Moment>where
    Moment: Sync,
    Value: Sync,

impl Sync for Event

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,

impl<K, V, Hasher> Sync for StorageMapIterator<K, V, Hasher>where
    Hasher: Sync,
    K: Sync,
    V: Sync,

impl<K, V, H> Sync for StorageMapIteratorShim<K, V, H>where
    H: Sync,
    K: Sync,
    V: Sync,

impl<T> Sync for MapIterator<T>

impl<T> Sync for MapIteratorShim<T>

impl Sync for OffchainErr

impl<T, S> Sync for OrderedSet<T, S>where
    S: Sync,
    T: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,

impl<T> Sync for GenesisConfig<T>where
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,
    <<T as Config>::Lookup as StaticLookup>::Source: Sync,

impl<BlockNumber, Balance> Sync for VestingSchedule<BlockNumber, Balance>where
    Balance: Sync,
    BlockNumber: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,

impl<Alternative, MultiCurrency, CurrencyId, AccountId, Balance> Sync for DepositToAlternative<Alternative, MultiCurrency, CurrencyId, AccountId, Balance>where
    AccountId: Sync,
    Alternative: Sync,
    Balance: Sync,
    CurrencyId: Sync,
    MultiCurrency: Sync,

impl<MultiCurrency, UnknownAsset, Match, AccountId, AccountIdConvert, CurrencyId, CurrencyIdConvert, DepositFailureHandler> Sync for MultiCurrencyAdapter<MultiCurrency, UnknownAsset, Match, AccountId, AccountIdConvert, CurrencyId, CurrencyIdConvert, DepositFailureHandler>where
    AccountId: Sync,
    AccountIdConvert: Sync,
    CurrencyId: Sync,
    CurrencyIdConvert: Sync,
    DepositFailureHandler: Sync,
    Match: Sync,
    MultiCurrency: Sync,
    UnknownAsset: Sync,

impl<CurrencyId, CurrencyIdConvert> Sync for IsNativeConcrete<CurrencyId, CurrencyIdConvert>where
    CurrencyId: Sync,
    CurrencyIdConvert: Sync,

impl<ReserveProvider> Sync for MultiNativeAsset<ReserveProvider>where
    ReserveProvider: Sync,

impl<T> Sync for Event<T>where
    T: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,

impl<'a, P> Sync for Split<'a, P>where
    <P as Pattern>::__Encoded: Sync,

impl Sync for RawOsStr

impl Sync for RawOsString

impl<O, H> Sync for OwningHandle<O, H>where
    H: Sync,
    O: Sync,

impl<AssetId> Sync for AssetType<AssetId>where
    AssetId: Sync,

impl<T> Sync for HydraWeight<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for GenesisConfig<T>

impl<T> Sync for Event<T>where
    T: Sync,
    <T as Config>::StringLimit: Sync,

impl<T> Sync for Call<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for GenesisConfig<T>

impl<T> Sync for Call<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,

impl<T> Sync for SealVerify<T>where
    T: Sync,

impl<T, N> Sync for OnePerAuthorPerHeight<T, N>where
    N: Sync,
    T: Sync,

impl<I, R, L> Sync for EquivocationHandler<I, R, L>where
    I: Sync,
    L: Sync,
    R: Sync,

impl<FullIdentification> Sync for BabeEquivocationOffence<FullIdentification>where
    FullIdentification: Sync,

impl<T> Sync for RandomnessFromTwoEpochsAgo<T>where
    T: Sync,

impl<T> Sync for RandomnessFromOneEpochAgo<T>where
    T: Sync,

impl<T> Sync for ParentBlockRandomness<T>where
    T: Sync,

impl<T> Sync for CurrentBlockRandomness<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,
    <T as Config>::KeyOwnerProof: Sync,

impl Sync for ListError

impl<T, I> Sync for List<T, I>where
    I: Sync,
    T: Sync,

impl<T, I> Sync for Bag<T, I>where
    I: Sync,
    <T as Config<I>>::Score: Sync,

impl<T, I> Sync for Node<T, I>where
    I: Sync,
    <T as Config<I>>::Score: Sync,

impl<T, I> Sync for CheckCounterPrefix<T, I>where
    I: Sync,
    T: Sync,

impl<T, I> Sync for AddScore<T, I>where
    I: Sync,
    T: Sync,

impl<T> Sync for SubstrateWeight<T>where
    T: Sync,

impl<T, I> Sync for Pallet<T, I>where
    I: Sync,
    T: Sync,

impl<T, I> Sync for Event<T, I>where
    I: Sync,
    T: Sync,
    <T as Config<I>>::Score: Sync,

impl<T, I> Sync for Error<T, I>where
    I: Sync,
    T: Sync,

impl<T, I> Sync for Call<T, I>where
    I: Sync,
    T: Sync,
    <<T as Config>::Lookup as StaticLookup>::Source: Sync,

impl<T> Sync for SubstrateWeight<T>where
    T: Sync,

impl<T, I> Sync for Pallet<T, I>where
    I: Sync,
    T: Sync,

impl<T, I> Sync for Event<T, I>where
    I: Sync,
    T: Sync,

impl<T, I> Sync for Error<T, I>where
    I: Sync,
    T: Sync,

impl<T, I> Sync for GenesisConfig<T, I>

impl<T, I> Sync for Call<T, I>where
    I: Sync,
    T: Sync,
    <<T as Config>::Lookup as StaticLookup>::Source: Sync,

impl<T, I> Sync for PositiveImbalance<T, I>

impl<T, I> Sync for NegativeImbalance<T, I>

impl Sync for Reasons

impl<Balance> Sync for BalanceLock<Balance>where
    Balance: Sync,

impl<ReserveIdentifier, Balance> Sync for ReserveData<ReserveIdentifier, Balance>where
    Balance: Sync,
    ReserveIdentifier: Sync,

impl<Balance> Sync for AccountData<Balance>where
    Balance: Sync,

impl<T, I> Sync for DustCleaner<T, I>

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for GenesisConfig<T>

impl<T> Sync for Call<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,

impl<T> Sync for DepositBeefyDigest<T>where
    T: Sync,

impl<T> Sync for SubstrateWeight<T>where
    T: Sync,

impl<T, I> Sync for Pallet<T, I>where
    I: Sync,
    T: Sync,

impl<T, I> Sync for Error<T, I>where
    I: Sync,
    T: Sync,

impl<T, I> Sync for Event<T, I>where
    I: Sync,
    T: Sync,
    <<T as Config<I>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,

impl<T, I> Sync for Call<T, I>where
    I: Sync,
    T: Sync,
    <<T as Config<I>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,
    <<T as Config>::Lookup as StaticLookup>::Source: Sync,

impl<AccountId, Balance, BlockNumber> Sync for Bounty<AccountId, Balance, BlockNumber>where
    AccountId: Sync,
    Balance: Sync,
    BlockNumber: Sync,

impl<AccountId, BlockNumber> Sync for BountyStatus<AccountId, BlockNumber>where
    AccountId: Sync,
    BlockNumber: Sync,

impl<T> Sync for SubstrateWeight<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,
    <<T as Config<()>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,

impl<T> Sync for Call<T>where
    T: Sync,
    <<T as Config<()>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,
    <<T as Config>::Lookup as StaticLookup>::Source: Sync,

impl<AccountId, Balance, BlockNumber> Sync for ChildBounty<AccountId, Balance, BlockNumber>where
    AccountId: Sync,
    Balance: Sync,
    BlockNumber: Sync,

impl<AccountId, BlockNumber> Sync for ChildBountyStatus<AccountId, BlockNumber>where
    AccountId: Sync,
    BlockNumber: Sync,

impl<T> Sync for SubstrateWeight<T>where
    T: Sync,

impl<AccountId, Balance> Sync for CandidateInfo<AccountId, Balance>where
    AccountId: Sync,
    Balance: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for GenesisConfig<T>where
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,

impl<T> Sync for Event<T>where
    T: Sync,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,

impl<T> Sync for SubstrateWeight<T>where
    T: Sync,

impl<T, I> Sync for Pallet<T, I>where
    I: Sync,
    T: Sync,

impl<T, I> Sync for GenesisConfig<T, I>where
    I: Sync,

impl<T, I> Sync for Event<T, I>where
    I: Sync,
    T: Sync,

impl<T, I> Sync for Error<T, I>where
    I: Sync,
    T: Sync,

impl<T, I> Sync for Call<T, I>where
    I: Sync,
    T: Sync,
    <T as Config<I>>::Proposal: Sync,

impl<AccountId, I> Sync for RawOrigin<AccountId, I>where
    AccountId: Sync,
    I: Sync,

impl<AccountId, BlockNumber> Sync for Votes<AccountId, BlockNumber>where
    AccountId: Sync,
    BlockNumber: Sync,

impl<AccountId, I> Sync for EnsureMember<AccountId, I>where
    AccountId: Sync,
    I: Sync,

impl<AccountId, I, const N: u32> Sync for EnsureMembers<AccountId, I, N>where
    AccountId: Sync,
    I: Sync,

impl<AccountId, I, const N: u32, const D: u32> Sync for EnsureProportionMoreThan<AccountId, I, N, D>where
    AccountId: Sync,
    I: Sync,

impl<AccountId, I, const N: u32, const D: u32> Sync for EnsureProportionAtLeast<AccountId, I, N, D>where
    AccountId: Sync,
    I: Sync,

impl<T> Sync for FungibleCurrencies<T>where
    T: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,
    <<T as Config>::MultiCurrency as MultiCurrencyExtended<<T as Config>::AccountId>>::Amount: Sync,
    <<T as Config>::MultiCurrency as MultiCurrency<<T as Config>::AccountId>>::Balance: Sync,
    <<T as Config>::MultiCurrency as MultiCurrency<<T as Config>::AccountId>>::CurrencyId: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,
    <<T as Config>::MultiCurrency as MultiCurrencyExtended<<T as Config>::AccountId>>::Amount: Sync,
    <<T as Config>::MultiCurrency as MultiCurrency<<T as Config>::AccountId>>::Balance: Sync,
    <<T as Config>::MultiCurrency as MultiCurrency<<T as Config>::AccountId>>::CurrencyId: Sync,
    <<T as Config>::Lookup as StaticLookup>::Source: Sync,

impl<T, GetCurrencyId> Sync for Currency<T, GetCurrencyId>where
    GetCurrencyId: Sync,
    T: Sync,

impl<T, Currency, Amount, Moment> Sync for BasicCurrencyAdapter<T, Currency, Amount, Moment>where
    Amount: Sync,
    Currency: Sync,
    Moment: Sync,
    T: Sync,

impl Sync for Conviction

impl<Balance> Sync for Tally<Balance>where
    Balance: Sync,

impl<Balance> Sync for Delegations<Balance>where
    Balance: Sync,

impl<BlockNumber, Hash, Balance> Sync for ReferendumStatus<BlockNumber, Hash, Balance>where
    Balance: Sync,
    BlockNumber: Sync,
    Hash: Sync,

impl<BlockNumber, Hash, Balance> Sync for ReferendumInfo<BlockNumber, Hash, Balance>where
    Balance: Sync,
    BlockNumber: Sync,
    Hash: Sync,

impl Sync for UnvoteScope

impl Sync for Vote

impl<Balance> Sync for AccountVote<Balance>where
    Balance: Sync,

impl<Balance, AccountId, BlockNumber> Sync for Voting<Balance, AccountId, BlockNumber>where
    AccountId: Sync,
    Balance: Sync,
    BlockNumber: Sync,

impl<T> Sync for SubstrateWeight<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for GenesisConfig<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,
    <<T as Config>::Lookup as StaticLookup>::Source: Sync,

impl<AccountId, Balance, BlockNumber> Sync for PreimageStatus<AccountId, Balance, BlockNumber>where
    AccountId: Sync,
    Balance: Sync,
    BlockNumber: Sync,

impl<T> Sync for HydraWeight<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for GenesisConfig<T>

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,

impl<T> Sync for DusterWhitelist<T>where
    T: Sync,

impl<AccountId, Balance, Solution> Sync for SignedSubmission<AccountId, Balance, Solution>where
    AccountId: Sync,
    Balance: Sync,
    Solution: Sync,

impl<T> Sync for InsertResult<T>where
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,
    <<T as Config>::MinerConfig as MinerConfig>::Solution: Sync,

impl<T> Sync for SignedSubmissions<T>where
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,
    <T as Config>::SignedMaxSubmissions: Sync,
    <<T as Config>::MinerConfig as MinerConfig>::Solution: Sync,

impl Sync for MinerError

impl<T> Sync for Miner<T>where
    T: Sync,

impl<T> Sync for SubstrateWeight<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,
    <<T as Config>::MinerConfig as MinerConfig>::Solution: Sync,

impl<T> Sync for NoFallback<T>where
    T: Sync,

impl<Bn> Sync for Phase<Bn>where
    Bn: Sync,

impl<S> Sync for RawSolution<S>where
    S: Sync,

impl<A> Sync for ReadySolution<A>where
    A: Sync,

impl<T> Sync for ElectionError<T>where
    <<T as Config>::Fallback as ElectionProvider>::Error: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for SubstrateWeight<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for GenesisConfig<T>where
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,

impl<T> Sync for Call<T>where
    T: Sync,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,
    <<T as Config>::Lookup as StaticLookup>::Source: Sync,

impl Sync for Renouncing

impl<AccountId, Balance> Sync for Voter<AccountId, Balance>where
    AccountId: Sync,
    Balance: Sync,

impl<AccountId, Balance> Sync for SeatHolder<AccountId, Balance>where
    AccountId: Sync,
    Balance: Sync,

impl<BlockNumber> Sync for OracleEntry<BlockNumber>where
    BlockNumber: Sync,

impl<T> Sync for BasiliskWeight<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,

impl<T> Sync for OnActivityHandler<T>where
    T: Sync,

impl Sync for OracleError

impl<T> Sync for SubstrateWeight<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<Balance, AccountId> Sync for GiltBid<Balance, AccountId>where
    AccountId: Sync,
    Balance: Sync,

impl<Balance, AccountId, BlockNumber> Sync for ActiveGilt<Balance, AccountId, BlockNumber>where
    AccountId: Sync,
    Balance: Sync,
    BlockNumber: Sync,

impl<Balance> Sync for ActiveGiltsTotal<Balance>where
    Balance: Sync,

impl<T> Sync for Event<T>where
    T: Sync,
    <T as Config>::CurrencyBalance: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<Balance> Sync for IssuanceInfo<Balance>where
    Balance: Sync,

impl<T> Sync for Call<T>where
    T: Sync,
    <T as Config>::CurrencyBalance: Sync,

impl<I, R, L, O> Sync for EquivocationHandler<I, R, L, O>where
    I: Sync,
    L: Sync,
    O: Sync,
    R: Sync,

impl<FullIdentification> Sync for GrandpaEquivocationOffence<FullIdentification>where
    FullIdentification: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl Sync for Event

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,
    <T as Config>::KeyOwnerProof: Sync,

impl<N, Limit> Sync for StoredPendingChange<N, Limit>where
    Limit: Sync,
    N: Sync,

impl<N> Sync for StoredState<N>where
    N: Sync,

impl Sync for Data

impl<Balance> Sync for Judgement<Balance>where
    Balance: Sync,

impl<FieldLimit> Sync for IdentityInfo<FieldLimit>where
    FieldLimit: Sync,

impl<Balance, MaxJudgements, MaxAdditionalFields> Sync for Registration<Balance, MaxJudgements, MaxAdditionalFields>where
    Balance: Sync,
    MaxAdditionalFields: Sync,
    MaxJudgements: Sync,

impl<Balance, AccountId> Sync for RegistrarInfo<Balance, AccountId>where
    AccountId: Sync,
    Balance: Sync,

impl<T> Sync for SubstrateWeight<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,

impl<T> Sync for Call<T>where
    T: Sync,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,
    <T as Config>::MaxAdditionalFields: Sync,
    <<T as Config>::Lookup as StaticLookup>::Source: Sync,

impl<T> Sync for SubstrateWeight<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,
    <<T as Config>::ValidatorSet as ValidatorSetWithIdentification<<T as Config>::AccountId>>::Identification: Sync,
    <<T as Config>::ValidatorSet as ValidatorSet<<T as Config>::AccountId>>::ValidatorId: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for GenesisConfig<T>

impl<T> Sync for Call<T>where
    T: Sync,
    <<T as Config>::AuthorityId as RuntimeAppPublic>::Signature: Sync,

impl<BlockNumber> Sync for Heartbeat<BlockNumber>where
    BlockNumber: Sync,

impl<PeerIdEncodingLimit, MultiAddrEncodingLimit, AddressesLimit> Sync for BoundedOpaqueNetworkState<PeerIdEncodingLimit, MultiAddrEncodingLimit, AddressesLimit>where
    AddressesLimit: Sync,
    MultiAddrEncodingLimit: Sync,
    PeerIdEncodingLimit: Sync,

impl<Offender> Sync for UnresponsivenessOffence<Offender>where
    Offender: Sync,

impl<T> Sync for SubstrateWeight<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for GenesisConfig<T>

impl<T> Sync for Call<T>where
    T: Sync,
    <<T as Config>::Lookup as StaticLookup>::Source: Sync,

impl Sync for create_pool

impl Sync for sell

impl Sync for buy

impl<T> Sync for HydraWeight<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,

impl<AccountId, BlockNumber> Sync for Pool<AccountId, BlockNumber>where
    AccountId: Sync,
    BlockNumber: Sync,

impl<T> Sync for DisallowWhenLBPPoolRunning<T>where
    T: Sync,

impl<T, I> Sync for GlobalFarmData<T, I>

impl<T, I> Sync for YieldFarmData<T, I>where
    I: Sync,

impl<T, I> Sync for DepositData<T, I>where
    I: Sync,
    <T as Config<I>>::MaxFarmEntriesPerDeposit: Sync,

impl<T, I> Sync for YieldFarmEntry<T, I>where
    I: Sync,

impl Sync for FarmState

impl<T, I> Sync for Pallet<T, I>where
    I: Sync,
    T: Sync,

impl<T, I> Sync for Error<T, I>where
    I: Sync,
    T: Sync,

impl<T, I> Sync for Event<T, I>where
    I: Sync,
    T: Sync,

impl<T, I> Sync for Call<T, I>where
    I: Sync,
    T: Sync,

impl<AccountId, Balance, BlockNumber> Sync for Offer<AccountId, Balance, BlockNumber>where
    AccountId: Sync,
    Balance: Sync,
    BlockNumber: Sync,

impl<AccountId> Sync for Royalty<AccountId>where
    AccountId: Sync,

impl<T> Sync for BasiliskWeight<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,

impl<T> Sync for SubstrateWeight<T>where
    T: Sync,

impl<T, I> Sync for Pallet<T, I>where
    I: Sync,
    T: Sync,

impl<T, I> Sync for GenesisConfig<T, I>where
    I: Sync,
    <T as Config<I>>::MaxMembers: Sync,

impl<T, I> Sync for Event<T, I>where
    I: Sync,
    T: Sync,
    <T as Config<I>>::Event: Sync,

impl<T, I> Sync for Error<T, I>where
    I: Sync,
    T: Sync,

impl<T, I> Sync for Call<T, I>where
    I: Sync,
    T: Sync,
    <<T as Config>::Lookup as StaticLookup>::Source: Sync,

impl<T, I> Sync for Pallet<T, I>where
    I: Sync,
    T: Sync,

impl<T, I> Sync for Call<T, I>where
    I: Sync,
    T: Sync,

impl<T> Sync for ParentNumberAndHash<T>where
    T: Sync,

impl<BlockHash> Sync for LeafProof<BlockHash>where
    BlockHash: Sync,

impl<BlockHash> Sync for LeafBatchProof<BlockHash>where
    BlockHash: Sync,

impl<Client, Block> Sync for Mmr<Client, Block>where
    Block: Sync,
    Client: Send + Sync,

impl<T> Sync for SubstrateWeight<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,
    <T as Config>::Call: Sync,

impl<BlockNumber> Sync for Timepoint<BlockNumber>where
    BlockNumber: Sync,

impl<BlockNumber, Balance, AccountId> Sync for Multisig<BlockNumber, Balance, AccountId>where
    AccountId: Sync,
    Balance: Sync,
    BlockNumber: Sync,

impl<CollectionType, BoundedVec> Sync for CollectionInfo<CollectionType, BoundedVec>where
    BoundedVec: Sync,
    CollectionType: Sync,

impl<BoundedVec> Sync for ItemInfo<BoundedVec>where
    BoundedVec: Sync,

impl<T> Sync for BasiliskWeight<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,
    <T as Config<()>>::StringLimit: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,
    <<T as Config>::Lookup as StaticLookup>::Source: Sync,
    <T as Config<()>>::StringLimit: Sync,

impl<AccountId> Sync for OldPoolRoles<AccountId>where
    AccountId: Sync,

impl<T> Sync for OldBondedPoolInner<T>where
    <T as Config>::CurrencyBalance: Sync,

impl<T> Sync for MigrateToV1<T>where
    T: Sync,

impl<B> Sync for OldRewardPool<B>where
    B: Sync,

impl<T> Sync for OldPoolMember<T>where
    <T as Config>::CurrencyBalance: Sync,
    <T as Config>::MaxUnbonding: Sync,

impl<T> Sync for MigrateToV2<T>where
    T: Sync,

impl<T> Sync for MigrateToV3<T>where
    T: Sync,

impl<T> Sync for SubstrateWeight<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for GenesisConfig<T>where
    <T as Config>::CurrencyBalance: Sync,

impl<T> Sync for Event<T>where
    T: Sync,
    <T as Config>::CurrencyBalance: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,
    <T as Config>::CurrencyBalance: Sync,
    <<T as Config>::Lookup as StaticLookup>::Source: Sync,

impl<T> Sync for ConfigOp<T>where
    T: Sync,

impl<Balance> Sync for BondExtra<Balance>where
    Balance: Sync,

impl<T> Sync for PoolMember<T>where
    <T as Config>::CurrencyBalance: Sync,
    <T as Config>::MaxUnbonding: Sync,
    <T as Config>::RewardCounter: Sync,

impl Sync for PoolState

impl<AccountId> Sync for PoolRoles<AccountId>where
    AccountId: Sync,

impl<T> Sync for BondedPoolInner<T>where
    <T as Config>::CurrencyBalance: Sync,

impl<T> Sync for BondedPool<T>where
    <T as Config>::CurrencyBalance: Sync,

impl<T> Sync for RewardPool<T>where
    <T as Config>::CurrencyBalance: Sync,
    <T as Config>::RewardCounter: Sync,

impl<T> Sync for UnbondPool<T>where
    <T as Config>::CurrencyBalance: Sync,

impl<T> Sync for SubPools<T>where
    T: Sync,
    <T as Config>::CurrencyBalance: Sync,

impl<T> Sync for TotalUnbondingPools<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl Sync for Event

impl<T> Sync for Call<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for SubstrateWeight<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,

impl<AccountId, Balance> Sync for RequestStatus<AccountId, Balance>where
    AccountId: Sync,
    Balance: Sync,

impl Sync for PriceEntry

impl Sync for PriceInfo

impl Sync for BucketQueue

impl<T> Sync for HydraWeight<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,

impl<T> Sync for PriceOracleHandler<T>where
    T: Sync,

impl<T> Sync for SubstrateWeight<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,
    <T as Config>::Call: Sync,
    <<T as Config>::Lookup as StaticLookup>::Source: Sync,

impl<AccountId, ProxyType, BlockNumber> Sync for ProxyDefinition<AccountId, ProxyType, BlockNumber>where
    AccountId: Sync,
    BlockNumber: Sync,
    ProxyType: Sync,

impl<AccountId, Hash, BlockNumber> Sync for Announcement<AccountId, Hash, BlockNumber>where
    AccountId: Sync,
    BlockNumber: Sync,
    Hash: Sync,

impl<T> Sync for SubstrateWeight<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,
    <T as Config>::Call: Sync,
    <<T as Config>::Lookup as StaticLookup>::Source: Sync,

impl<BlockNumber, Balance, Friends> Sync for ActiveRecovery<BlockNumber, Balance, Friends>where
    Balance: Sync,
    BlockNumber: Sync,
    Friends: Sync,

impl<BlockNumber, Balance, Friends> Sync for RecoveryConfig<BlockNumber, Balance, Friends>where
    Balance: Sync,
    BlockNumber: Sync,
    Friends: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,

impl<T> Sync for OnValidationDataHandler<T>where
    T: Sync,

impl<T> Sync for BasiliskWeight<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,

impl<AssetId> Sync for Trade<AssetId>where
    AssetId: Sync,

impl<T> Sync for SubstrateWeight<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,
    <T as Config>::Call: Sync,

impl<Call, BlockNumber, PalletsOrigin, AccountId> Sync for ScheduledV3<Call, BlockNumber, PalletsOrigin, AccountId>where
    AccountId: Sync,
    BlockNumber: Sync,
    Call: Sync,
    PalletsOrigin: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,

impl<T, I> Sync for NoteHistoricalRoot<T, I>where
    I: Sync,
    T: Sync,

impl<T> Sync for ProvingTrie<T>

impl<T> Sync for SubstrateWeight<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for GenesisConfig<T>

impl Sync for Event

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,

impl<Period, Offset> Sync for PeriodicSessions<Period, Offset>where
    Offset: Sync,
    Period: Sync,

impl<T, Inner> Sync for FindAccountFromAuthorIndex<T, Inner>where
    Inner: Sync,
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T, I> Sync for Pallet<T, I>where
    I: Sync,
    T: Sync,

impl<T, I> Sync for Error<T, I>where
    I: Sync,
    T: Sync,

impl<T, I> Sync for Event<T, I>where
    I: Sync,
    T: Sync,
    <<T as Config<I>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,

impl<T, I> Sync for GenesisConfig<T, I>where
    <<T as Config<I>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,

impl<T, I> Sync for Call<T, I>where
    I: Sync,
    T: Sync,
    <<T as Config<I>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,
    <<T as Config>::Lookup as StaticLookup>::Source: Sync,

impl Sync for Vote

impl Sync for Judgement

impl<Balance, BlockNumber> Sync for Payout<Balance, BlockNumber>where
    Balance: Sync,
    BlockNumber: Sync,

impl<AccountId, Balance> Sync for Bid<AccountId, Balance>where
    AccountId: Sync,
    Balance: Sync,

impl<AccountId, Balance> Sync for BidKind<AccountId, Balance>where
    AccountId: Sync,
    Balance: Sync,

impl<T> Sync for EnsureFounder<T>where
    T: Sync,

impl<T> Sync for MigrateToV10<T>where
    T: Sync,

impl<T> Sync for InjectValidatorsIntoVoterList<T>where
    T: Sync,

impl<T> Sync for SubstrateWeight<T>where
    T: Sync,

impl<T> Sync for UseNominatorsAndValidatorsMap<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for ConfigOp<T>where
    T: Sync,

impl<T> Sync for GenesisConfig<T>where
    <T as Config>::CurrencyBalance: Sync,

impl<T> Sync for Event<T>where
    T: Sync,
    <T as Config>::CurrencyBalance: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,
    <T as Config>::CurrencyBalance: Sync,
    <<T as Config>::Lookup as StaticLookup>::Source: Sync,

impl<AccountId> Sync for EraRewardPoints<AccountId>where
    AccountId: Sync,

impl<AccountId> Sync for StakerStatus<AccountId>where
    AccountId: Sync,

impl<AccountId> Sync for RewardDestination<AccountId>where
    AccountId: Sync,

impl<Balance> Sync for UnlockChunk<Balance>where
    Balance: Sync,

impl<T> Sync for StakingLedger<T>where
    <T as Config>::CurrencyBalance: Sync,

impl<T> Sync for Nominations<T>where
    <T as Config>::MaxNominations: Sync,

impl<AccountId, Balance> Sync for IndividualExposure<AccountId, Balance>where
    AccountId: Sync,
    Balance: Sync,

impl<AccountId, Balance> Sync for Exposure<AccountId, Balance>where
    AccountId: Sync,
    Balance: Sync,

impl<AccountId, Balance> Sync for UnappliedSlash<AccountId, Balance>where
    AccountId: Sync,
    Balance: Sync,

impl<T> Sync for ConvertCurve<T>where
    T: Sync,

impl Sync for Forcing

impl<T> Sync for StashOf<T>where
    T: Sync,

impl<T> Sync for ExposureOf<T>where
    T: Sync,

impl<T, R> Sync for FilterHistoricalOffences<T, R>where
    R: Sync,
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for GenesisConfig<T>

impl<T> Sync for Call<T>where
    T: Sync,
    <T as Config>::Call: Sync,
    <<T as Config>::Lookup as StaticLookup>::Source: Sync,

impl<T> Sync for SubstrateWeight<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,
    <T as Config>::Moment: Sync,

impl<T> Sync for SubstrateWeight<T>where
    T: Sync,

impl<T, I> Sync for Pallet<T, I>where
    I: Sync,
    T: Sync,

impl<T, I> Sync for Event<T, I>where
    I: Sync,
    T: Sync,
    <<T as Config<I>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,

impl<T, I> Sync for Error<T, I>where
    I: Sync,
    T: Sync,

impl<T, I> Sync for Call<T, I>where
    I: Sync,
    T: Sync,
    <<T as Config<I>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,
    <<T as Config>::Lookup as StaticLookup>::Source: Sync,

impl<AccountId, Balance, BlockNumber, Hash> Sync for OpenTip<AccountId, Balance, BlockNumber, Hash>where
    AccountId: Sync,
    Balance: Sync,
    BlockNumber: Sync,
    Hash: Sync,

impl<T> Sync for BasiliskWeight<T>where
    T: Sync,

impl<Balance, AssetId, Price> Sync for PaymentInfo<Balance, AssetId, Price>where
    AssetId: Sync,
    Balance: Sync,
    Price: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,
    <<T as Config>::Currencies as MultiCurrency<<T as Config>::AccountId>>::Balance: Sync,
    <<T as Config>::Currencies as MultiCurrency<<T as Config>::AccountId>>::CurrencyId: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for GenesisConfig<T>where
    <<T as Config>::Currencies as MultiCurrency<<T as Config>::AccountId>>::CurrencyId: Sync,

impl<T> Sync for Call<T>where
    T: Sync,
    <<T as Config>::Currencies as MultiCurrency<<T as Config>::AccountId>>::CurrencyId: Sync,

impl<T> Sync for DepositAll<T>where
    T: Sync,

impl<MC, DP, DF> Sync for TransferFees<MC, DP, DF>where
    DF: Sync,
    DP: Sync,
    MC: Sync,

impl<C, OU, SW> Sync for WithdrawFees<C, OU, SW>where
    C: Sync,
    OU: Sync,
    SW: Sync,

impl<T> Sync for CurrencyBalanceCheck<T>

impl<T> Sync for AddTxAssetOnAccount<T>where
    T: Sync,

impl<T> Sync for RemoveTxAssetOnKilled<T>where
    T: Sync,

impl<T> Sync for AcalaWeight<T>where
    T: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,

impl<T> Sync for PausedTransactionFilter<T>where
    T: Sync,

impl<C, OU> Sync for CurrencyAdapter<C, OU>where
    C: Sync,
    OU: Sync,

impl<Balance> Sync for InclusionFee<Balance>where
    Balance: Sync,

impl<Balance> Sync for FeeDetails<Balance>where
    Balance: Sync,

impl<Balance> Sync for RuntimeDispatchInfo<Balance>where
    Balance: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,
    <<T as Config>::OnChargeTransaction as OnChargeTransaction<T>>::Balance: Sync,

impl<T> Sync for Call<T>where
    T: Sync,

impl<T, S, V, M> Sync for TargetedFeeAdjustment<T, S, V, M>where
    M: Sync,
    S: Sync,
    T: Sync,
    V: Sync,

impl<C, P> Sync for TransactionPayment<C, P>where
    C: Send + Sync,
    P: Sync,

impl Sync for Error

impl<T> Sync for SubstrateWeight<T>where
    T: Sync,

impl<T, I> Sync for Pallet<T, I>where
    I: Sync,
    T: Sync,

impl<T, I> Sync for Event<T, I>where
    I: Sync,
    T: Sync,
    <<T as Config<I>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,

impl<T, I> Sync for Error<T, I>where
    I: Sync,
    T: Sync,

impl<T, I> Sync for Call<T, I>where
    I: Sync,
    T: Sync,
    <<T as Config<I>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,
    <<T as Config>::Lookup as StaticLookup>::Source: Sync,

impl<AccountId, Balance> Sync for Proposal<AccountId, Balance>where
    AccountId: Sync,
    Balance: Sync,

impl<AccountId, DepositBalance> Sync for CollectionDetails<AccountId, DepositBalance>where
    AccountId: Sync,
    DepositBalance: Sync,

impl<AccountId, DepositBalance> Sync for ItemDetails<AccountId, DepositBalance>where
    AccountId: Sync,
    DepositBalance: Sync,

impl<DepositBalance, StringLimit> Sync for CollectionMetadata<DepositBalance, StringLimit>where
    DepositBalance: Sync,
    StringLimit: Sync,

impl<DepositBalance, StringLimit> Sync for ItemMetadata<DepositBalance, StringLimit>where
    DepositBalance: Sync,
    StringLimit: Sync,

impl<T> Sync for SubstrateWeight<T>where
    T: Sync,

impl<T, I> Sync for Pallet<T, I>where
    I: Sync,
    T: Sync,

impl<T, I> Sync for Event<T, I>where
    I: Sync,
    T: Sync,
    <<T as Config<I>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,
    <T as Config<I>>::KeyLimit: Sync,
    <T as Config<I>>::StringLimit: Sync,
    <T as Config<I>>::ValueLimit: Sync,

impl<T, I> Sync for Error<T, I>where
    I: Sync,
    T: Sync,

impl<T, I> Sync for Call<T, I>where
    I: Sync,
    T: Sync,
    <<T as Config<I>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,
    <T as Config<I>>::KeyLimit: Sync,
    <<T as Config>::Lookup as StaticLookup>::Source: Sync,
    <T as Config<I>>::StringLimit: Sync,
    <T as Config<I>>::ValueLimit: Sync,

impl<T> Sync for SubstrateWeight<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl Sync for Event

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,
    <T as Config>::Call: Sync,
    <T as Config>::PalletsOrigin: Sync,

impl<Balance, BlockNumber> Sync for VestingInfo<Balance, BlockNumber>where
    Balance: Sync,
    BlockNumber: Sync,

impl<T> Sync for SubstrateWeight<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for GenesisConfig<T>where
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,

impl<T> Sync for Event<T>where
    T: Sync,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,
    <<T as Config>::Lookup as StaticLookup>::Source: Sync,

impl<T> Sync for MaxVestingSchedulesGet<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,

impl Sync for Origin

impl<T> Sync for Error<T>where
    T: Sync,

impl<BlockNumber> Sync for QueryStatus<BlockNumber>where
    BlockNumber: Sync,

impl<T> Sync for VersionDiscoveryQueueSize<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,
    <T as Config>::Call: Sync,

impl<Prefix, Body> Sync for IsMajorityOfBody<Prefix, Body>where
    Body: Sync,
    Prefix: Sync,

impl<F> Sync for EnsureXcm<F>where
    F: Sync,

impl<F> Sync for EnsureResponse<F>where
    F: Sync,

impl<Origin> Sync for XcmPassthrough<Origin>where
    Origin: Sync,

impl<T, I> Sync for Pallet<T, I>where
    I: Sync,
    T: Sync,

impl<T, I> Sync for Call<T, I>where
    I: Sync,
    T: Sync,

impl<T, I> Sync for Pallet<T, I>where
    I: Sync,
    T: Sync,

impl<T, I> Sync for Call<T, I>where
    I: Sync,
    T: Sync,

impl Sync for create_pool

impl Sync for sell

impl Sync for buy

impl<T> Sync for XYKSpotPrice<T>where
    T: Sync,

impl<T> Sync for HydraWeight<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,

impl<T> Sync for BasiliskWeight<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,

impl Sync for SS58Prefix

impl Sync for MaxLocks

impl Sync for MaxReserves

impl Sync for Ancestry

impl Sync for BlockLength

impl Sync for BaseRate

impl Sync for XcmConfig

impl Sync for Event

impl !Sync for Origin

impl Sync for PalletInfo

impl Sync for Call

impl<'a> Sync for BTreeIterator<'a>

impl Sync for Db

impl<Key, Value> Sync for Operation<Key, Value>where
    Key: Sync,
    Value: Sync,

impl Sync for Error

impl Sync for Options

impl Sync for StatSummary

impl<R> Sync for IoReader<R>where
    R: Sync,

impl Sync for OptionBool

impl<T> Sync for Compact<T>where
    T: Sync,

impl<'a, T> Sync for CompactRef<'a, T>where
    T: Sync,

impl<'a, T, U> Sync for Ref<'a, T, U>where
    T: Sync,
    U: Sync,

impl Sync for Error

impl Sync for VarUint32

impl Sync for VarUint64

impl Sync for VarUint7

impl Sync for VarInt7

impl Sync for Uint8

impl Sync for VarInt32

impl Sync for VarInt64

impl Sync for Uint32

impl Sync for Uint64

impl Sync for VarUint1

impl<T> Sync for CountedList<T>where
    T: Sync,

impl<'a, W> Sync for CountedWriter<'a, W>where
    W: Sync,

impl<I, T> Sync for CountedListWriter<I, T>where
    T: Sync,

impl Sync for Module

impl Sync for Section

impl Sync for TypeSection

impl Sync for CodeSection

impl Sync for DataSection

impl Sync for Type

impl Sync for ValueType

impl Sync for BlockType

impl Sync for GlobalType

impl Sync for TableType

impl Sync for MemoryType

impl Sync for External

impl Sync for ImportEntry

impl Sync for Internal

impl Sync for ExportEntry

impl Sync for GlobalEntry

impl Sync for InitExpr

impl Sync for Instruction

impl Sync for BrTableData

impl Sync for Func

impl Sync for Local

impl Sync for FuncBody

impl Sync for DataSegment

impl<T> Sync for IndexMap<T>where
    T: Sync,

impl Sync for NameSection

impl Sync for Error

impl Sync for Unparsed

impl Sync for Identity

impl<F> Sync for ModuleBuilder<F>where
    F: Sync,

impl<F> Sync for SignatureBuilder<F>where
    F: Sync,

impl<F> Sync for TypeRefBuilder<F>where
    F: Sync,

impl<F> Sync for SignaturesBuilder<F>where
    F: Sync,

impl<F> Sync for FuncBodyBuilder<F>where
    F: Sync,

impl<F> Sync for FunctionBuilder<F>where
    F: Sync,

impl<F> Sync for ImportBuilder<F>where
    F: Sync,

impl<F> Sync for MemoryBuilder<F>where
    F: Sync,

impl<F> Sync for TableBuilder<F>where
    F: Sync,

impl<F> Sync for ExportBuilder<F>where
    F: Sync,

impl<F> Sync for ExportInternalBuilder<F>where
    F: Sync,

impl<F> Sync for GlobalBuilder<F>where
    F: Sync,

impl<F> Sync for DataSegmentBuilder<F>where
    F: Sync,

impl !Sync for Parker

impl Sync for Unparker

impl Sync for Condvar

impl Sync for OnceState

impl Sync for Once

impl Sync for RawMutex

impl Sync for RawRwLock

impl Sync for RawThreadId

impl Sync for ParkResult

impl Sync for RequeueOp

impl Sync for FilterOp

impl Sync for UnparkToken

impl Sync for ParkToken

impl Sync for SpinWait

impl Sync for AsciiSet

impl<'a> Sync for PercentEncode<'a>

impl<'a> Sync for PercentDecode<'a>

impl<R> Sync for Error<R>where
    R: Sync,

impl<R> Sync for ErrorVariant<R>where
    R: Sync,

impl<'i, R> !Sync for FlatPairs<'i, R>

impl<'i, R> !Sync for Pair<'i, R>

impl<'i, R> !Sync for Pairs<'i, R>

impl<'i, R> !Sync for Tokens<'i, R>

impl Sync for Lookahead

impl Sync for Atomicity

impl Sync for MatchDir

impl<'i, R> Sync for ParserState<'i, R>where
    R: Sync,

impl<'i> Sync for Position<'i>

impl Sync for Assoc

impl<R> Sync for Op<R>where
    R: Sync,

impl<R> Sync for PrattParser<R>where
    R: Sync,

impl<'pratt, 'i, R, F, T> !Sync for PrattParserMap<'pratt, 'i, R, F, T>

impl Sync for Assoc

impl<R> Sync for Operator<R>where
    R: Sync,

impl<R> Sync for PrecClimber<R>where
    R: Sync,

impl<'i> Sync for Span<'i>

impl<'i> Sync for LinesSpan<'i>

impl<'i> Sync for Lines<'i>

impl<'i, R> Sync for Token<'i, R>where
    R: Sync,

impl Sync for Rule

impl Sync for RuleType

impl Sync for Expr

impl Sync for PestParser

impl Sync for Rule

impl<'i> Sync for ParserRule<'i>

impl<'i> Sync for ParserNode<'i>

impl<'i> Sync for ParserExpr<'i>

impl Sync for Time

impl<N> Sync for DfsEvent<N>where
    N: Sync,

impl<B> Sync for Control<B>where
    B: Sync,

impl<N, VM> Sync for Dfs<N, VM>where
    N: Sync,
    VM: Sync,

impl<N, VM> Sync for DfsPostOrder<N, VM>where
    N: Sync,
    VM: Sync,

impl<N, VM> Sync for Bfs<N, VM>where
    N: Sync,
    VM: Sync,

impl<N, VM> Sync for Topo<N, VM>where
    N: Sync,
    VM: Sync,

impl<W, C> Sync for WalkerIter<W, C>where
    C: Sync,
    W: Sync,

impl<G, F> Sync for NodeFiltered<G, F>where
    F: Sync,
    G: Sync,

impl<'a, I, F> Sync for NodeFilteredNeighbors<'a, I, F>where
    F: Sync,
    I: Sync,

impl<'a, I, F> Sync for NodeFilteredNodes<'a, I, F>where
    F: Sync,
    I: Sync,

impl<'a, G, I, F> Sync for NodeFilteredEdgeReferences<'a, G, I, F>where
    F: Sync,
    G: Sync,
    I: Sync,

impl<'a, G, I, F> Sync for NodeFilteredEdges<'a, G, I, F>where
    F: Sync,
    G: Sync,
    I: Sync,

impl<G, F> Sync for EdgeFiltered<G, F>where
    F: Sync,
    G: Sync,

impl<'a, G, F> Sync for EdgeFilteredNeighbors<'a, G, F>where
    F: Sync,
    <G as IntoEdges>::Edges: Sync,

impl<'a, G, I, F> Sync for EdgeFilteredEdges<'a, G, I, F>where
    F: Sync,
    G: Sync,
    I: Sync,

impl<'a, G, F> Sync for EdgeFilteredNeighborsDirected<'a, G, F>where
    F: Sync,
    <G as IntoEdgesDirected>::EdgesDirected: Sync,
    <G as GraphBase>::NodeId: Sync,

impl<G> Sync for Reversed<G>where
    G: Sync,

impl<I> Sync for ReversedEdges<I>where
    I: Sync,

impl<R> Sync for ReversedEdgeReference<R>where
    R: Sync,

impl<I> Sync for ReversedEdgeReferences<I>where
    I: Sync,

impl<N, E> Sync for Element<N, E>where
    E: Sync,
    N: Sync,

impl<I, F> Sync for FilterElements<I, F>where
    F: Sync,
    I: Sync,

impl<Ix> Sync for EdgeIndex<Ix>where
    Ix: Sync,

impl<Ix> Sync for OutgoingEdgeIndices<Ix>where
    Ix: Sync,

impl<'a, E, Ix> Sync for Neighbors<'a, E, Ix>where
    E: Sync,
    Ix: Sync,

impl<'a, E, Ix> Sync for EdgeReference<'a, E, Ix>where
    E: Sync,
    Ix: Sync,

impl<'a, E, Ix> Sync for EdgeIndices<'a, E, Ix>where
    E: Sync,
    Ix: Sync,

impl<Ix> Sync for NodeIndices<Ix>

impl<E, Ix> Sync for List<E, Ix>where
    E: Sync,
    Ix: Sync,

impl<'a, E, Ix> Sync for EdgeReferences<'a, E, Ix>where
    E: Sync,
    Ix: Sync,

impl<'a, E, Ix> Sync for OutgoingEdgeReferences<'a, E, Ix>where
    E: Sync,
    Ix: Sync,

impl<NodeId, EdgeWeight> Sync for Paths<NodeId, EdgeWeight>where
    EdgeWeight: Sync,
    NodeId: Sync,

impl<N> Sync for Dominators<N>where
    N: Sync,

impl<'a, N> Sync for DominatorsIter<'a, N>where
    N: Sync,

impl<'a, N> Sync for DominatedByIter<'a, N>where
    N: Sync,

impl<G> Sync for Matching<G>where
    G: Sync,
    <G as GraphBase>::NodeId: Sync,

impl<'a, G> Sync for MatchedNodes<'a, G>where
    G: Sync,
    <G as GraphBase>::NodeId: Sync,

impl<'a, G> Sync for MatchedEdges<'a, G>where
    G: Sync,
    <G as GraphBase>::NodeId: Sync,

impl<N, VM> Sync for DfsSpace<N, VM>where
    N: Sync,
    VM: Sync,

impl<N> Sync for TarjanScc<N>where
    N: Sync,

impl<G> Sync for MinSpanningTree<G>where
    G: Sync,
    <G as Data>::EdgeWeight: Sync,
    <G as GraphBase>::NodeId: Sync,
    <G as IntoNodeReferences>::NodeReferences: Sync,

impl<N> Sync for Cycle<N>where
    N: Sync,

impl<N, E, Ty, Ix> Sync for Csr<N, E, Ty, Ix>where
    E: Sync,
    Ix: Sync,
    N: Sync,
    Ty: Sync,

impl<'a, E, Ty, Ix> Sync for Edges<'a, E, Ty, Ix>where
    E: Sync,
    Ix: Sync,
    Ty: Sync,

impl<'a, E, Ty, Ix> Sync for EdgeReference<'a, E, Ty, Ix>where
    E: Sync,
    Ix: Sync,
    Ty: Sync,

impl<'a, E, Ty, Ix> Sync for EdgeReferences<'a, E, Ty, Ix>where
    E: Sync,
    Ix: Sync,
    Ty: Sync,

impl<'a, Ix> Sync for Neighbors<'a, Ix>where
    Ix: Sync,

impl<Ix> Sync for NodeIdentifiers<Ix>where
    Ix: Sync,

impl<'a, N, Ix> Sync for NodeReferences<'a, N, Ix>where
    Ix: Sync,
    N: Sync,

impl<'a, G> !Sync for Dot<'a, G>

impl Sync for Config

impl<N, E, Ty, Ix> Sync for StableGraph<N, E, Ty, Ix>where
    E: Sync,
    Ix: Sync,
    N: Sync,
    Ty: Sync,

impl<'a, N, Ix> Sync for NodeReferences<'a, N, Ix>where
    Ix: Sync,
    N: Sync,

impl<'a, E, Ix> Sync for EdgeReference<'a, E, Ix>where
    E: Sync,
    Ix: Sync,

impl<'a, E, Ty, Ix> Sync for Edges<'a, E, Ty, Ix>where
    E: Sync,
    Ix: Sync,
    Ty: Sync,

impl<'a, E, Ix> Sync for EdgeReferences<'a, E, Ix>where
    E: Sync,
    Ix: Sync,

impl<'a, N, Ty, Ix> Sync for Externals<'a, N, Ty, Ix>where
    Ix: Sync,
    N: Sync,
    Ty: Sync,

impl<'a, E, Ix> Sync for Neighbors<'a, E, Ix>where
    E: Sync,
    Ix: Sync,

impl<Ix> Sync for WalkNeighbors<Ix>where
    Ix: Sync,

impl<'a, N, Ix> Sync for NodeIndices<'a, N, Ix>where
    Ix: Sync,
    N: Sync,

impl<'a, E, Ix> Sync for EdgeIndices<'a, E, Ix>where
    E: Sync,
    Ix: Sync,

impl<Ix> Sync for NodeIndex<Ix>where
    Ix: Sync,

impl<Ix> Sync for EdgeIndex<Ix>where
    Ix: Sync,

impl<N, Ix> Sync for Node<N, Ix>where
    Ix: Sync,
    N: Sync,

impl<E, Ix> Sync for Edge<E, Ix>where
    E: Sync,
    Ix: Sync,

impl<N, E, Ty, Ix> Sync for Graph<N, E, Ty, Ix>where
    E: Sync,
    Ix: Sync,
    N: Sync,
    Ty: Sync,

impl<'a, N, Ty, Ix> Sync for Externals<'a, N, Ty, Ix>where
    Ix: Sync,
    N: Sync,
    Ty: Sync,

impl<'a, E, Ix> Sync for Neighbors<'a, E, Ix>where
    E: Sync,
    Ix: Sync,

impl<'a, E, Ty, Ix> Sync for Edges<'a, E, Ty, Ix>where
    E: Sync,
    Ix: Sync,
    Ty: Sync,

impl<'a, E, Ty, Ix> Sync for EdgesConnecting<'a, E, Ty, Ix>where
    E: Sync,
    Ix: Sync,
    Ty: Sync,

impl<'a, N, Ix> Sync for NodeWeightsMut<'a, N, Ix>where
    Ix: Sync,
    N: Sync,

impl<'a, E, Ix> Sync for EdgeWeightsMut<'a, E, Ix>where
    E: Sync,
    Ix: Sync,

impl<Ix> Sync for WalkNeighbors<Ix>where
    Ix: Sync,

impl<Ix> Sync for NodeIndices<Ix>

impl<Ix> Sync for EdgeIndices<Ix>

impl<'a, E, Ix> Sync for EdgeReference<'a, E, Ix>where
    E: Sync,
    Ix: Sync,

impl<'a, N, Ix> Sync for NodeReferences<'a, N, Ix>where
    Ix: Sync,
    N: Sync,

impl<'a, E, Ix> Sync for EdgeReferences<'a, E, Ix>where
    E: Sync,
    Ix: Sync,

impl<'a, G> Sync for Frozen<'a, G>where
    G: Sync,

impl<N, E, Ty> Sync for GraphMap<N, E, Ty>where
    E: Sync,
    N: Sync,
    Ty: Sync,

impl<'a, N> Sync for Nodes<'a, N>where
    N: Sync,

impl<'a, N, Ty> Sync for Neighbors<'a, N, Ty>where
    N: Sync,
    Ty: Sync,

impl<'a, N, Ty> Sync for NeighborsDirected<'a, N, Ty>where
    N: Sync,
    Ty: Sync,

impl<'a, N, E, Ty> Sync for Edges<'a, N, E, Ty>where
    E: Sync,
    N: Sync,
    Ty: Sync,

impl<'a, N, E, Ty> Sync for EdgesDirected<'a, N, E, Ty>where
    E: Sync,
    N: Sync,
    Ty: Sync,

impl<'a, N, E, Ty> Sync for AllEdges<'a, N, E, Ty>where
    E: Sync,
    N: Sync,
    Ty: Sync,

impl<'a, N, E, Ty> Sync for AllEdgesMut<'a, N, E, Ty>where
    E: Sync,
    N: Sync,
    Ty: Sync,

impl<'b, T> Sync for Ptr<'b, T>where
    T: Sync,

impl<'a, N, E, Ty> Sync for NodeIdentifiers<'a, N, E, Ty>where
    E: Sync,
    N: Sync,
    Ty: Sync,

impl<'a, N, E, Ty> Sync for NodeReferences<'a, N, E, Ty>where
    E: Sync,
    N: Sync,
    Ty: Sync,

impl<T> Sync for NotZero<T>where
    T: Sync,

impl<N, E, Ty, Null, Ix> Sync for MatrixGraph<N, E, Ty, Null, Ix>where
    Ix: Sync,
    N: Sync,
    Null: Sync,
    Ty: Sync,

impl<'a, Ix> Sync for NodeIdentifiers<'a, Ix>where
    Ix: Sync,

impl<'a, N, Ix> Sync for NodeReferences<'a, N, Ix>where
    Ix: Sync,
    N: Sync,

impl<'a, Ty, Null, Ix> Sync for EdgeReferences<'a, Ty, Null, Ix>where
    Ix: Sync,
    Null: Sync,
    Ty: Sync,

impl<'a, Ty, Null, Ix> Sync for Neighbors<'a, Ty, Null, Ix>where
    Ix: Sync,
    Null: Sync,
    Ty: Sync,

impl<'a, Ty, Null, Ix> Sync for Edges<'a, Ty, Null, Ix>where
    Ix: Sync,
    Null: Sync,
    Ty: Sync,

impl<K> Sync for UnionFind<K>where
    K: Sync,

impl Sync for Direction

impl Sync for Directed

impl Sync for Undirected

impl Sync for Metrics

impl Sync for Subcommand

impl Sync for RunCmd

impl Sync for Cli

impl Sync for Client

impl<BlockNumber> Sync for InboundDownwardMessage<BlockNumber>where
    BlockNumber: Sync,

impl<BlockNumber> Sync for InboundHrmpMessage<BlockNumber>where
    BlockNumber: Sync,

impl<Id> Sync for OutboundHrmpMessage<Id>where
    Id: Sync,

impl Sync for Metrics

impl<AD> Sync for DisputeDistributionSubsystem<AD>where
    AD: Sync,

impl Sync for Error

impl<'a, I> Sync for Branches<'a, I>where
    I: Sync,

impl<AD> Sync for GossipSupport<AD>where
    AD: Sync,

impl Sync for Metrics

impl<N, AD> Sync for NetworkBridgeTx<N, AD>where
    AD: Sync,
    N: Sync,

impl<N, AD> !Sync for NetworkBridgeRx<N, AD>

impl Sync for Config

impl Sync for Metrics

impl Sync for Metrics

impl Sync for Error

impl Sync for Config

impl Sync for Error

impl Sync for Config

impl<Client> Sync for ChainApiSubsystem<Client>where
    Client: Send + Sync,

impl Sync for Error

impl Sync for Config

impl Sync for Config

impl Sync for Error

impl Sync for Metrics

impl Sync for Config

impl Sync for Metrics

impl Sync for Priority

impl Sync for Pvf

impl<Client> Sync for RuntimeApiSubsystem<Client>where
    Client: Send + Sync,

impl Sync for JaegerError

impl Sync for PerLeafSpan

impl Sync for Stage

impl Sync for Span

impl Sync for Jaeger

impl Sync for Metronome

impl Sync for PeerSet

impl Sync for PeerSetIter

impl Sync for IsAuthority

impl<T> Sync for PerPeerSet<T>where
    T: Sync,

impl Sync for Error

impl Sync for FatalError

impl Sync for JfyiError

impl<Req> Sync for IncomingRequest<Req>where
    Req: Sync,

impl<Req> Sync for OutgoingResponseSender<Req>where
    Req: Sync,

impl<Response> Sync for OutgoingResponse<Response>where
    Response: Sync,

impl<Req> Sync for IncomingRequestReceiver<Req>where
    Req: Sync,

impl Sync for Requests

impl<Req> Sync for OutgoingRequest<Req>where
    Req: Sync,

impl Sync for Recipient

impl Sync for Protocol

impl Sync for OurView

impl Sync for View

impl<V1> Sync for Versioned<V1>where
    V1: Sync,

impl Sync for Error

impl Sync for Statement

impl Sync for PoV

impl<BlockNumber> Sync for Collation<BlockNumber>where
    BlockNumber: Sync,

impl Sync for Proof

impl<M> Sync for NetworkBridgeEvent<M>where
    M: Sync,

impl Sync for LeafStatus

impl Sync for Error

impl Sync for FatalError

impl Sync for JfyiError

impl Sync for Config

impl Sync for RuntimeInfo

impl<D> Sync for DbAdapter<D>where
    D: Sync,

impl Sync for DbAdapter

impl Sync for Error

impl Sync for Validator

impl Sync for Metrics

impl<S> Sync for SpawnGlue<S>where
    S: Sync,

impl Sync for Handle

impl Sync for BlockInfo

impl Sync for Event

impl<S, SupportsParachains> !Sync for Overseer<S, SupportsParachains>

impl<T> !Sync for Init<T>

impl<T> Sync for Missing<T>where
    T: Sync,

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> Sync 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: Sync,
    InitStateBaggage1: Sync,
    InitStateBaggage2: Sync,
    InitStateBaggage3: Sync,
    InitStateBaggage4: Sync,
    InitStateBaggage5: Sync,
    InitStateBaggage6: Sync,
    InitStateSpawner: Sync,
    InitStateSubsystem0: Sync,
    InitStateSubsystem1: Sync,
    InitStateSubsystem10: Sync,
    InitStateSubsystem11: Sync,
    InitStateSubsystem12: Sync,
    InitStateSubsystem13: Sync,
    InitStateSubsystem14: Sync,
    InitStateSubsystem15: Sync,
    InitStateSubsystem16: Sync,
    InitStateSubsystem17: Sync,
    InitStateSubsystem18: Sync,
    InitStateSubsystem19: Sync,
    InitStateSubsystem2: Sync,
    InitStateSubsystem20: Sync,
    InitStateSubsystem21: Sync,
    InitStateSubsystem3: Sync,
    InitStateSubsystem4: Sync,
    InitStateSubsystem5: Sync,
    InitStateSubsystem6: Sync,
    InitStateSubsystem7: Sync,
    InitStateSubsystem8: Sync,
    InitStateSubsystem9: Sync,

impl<M> Sync for OrchestratedSubsystem<M>where
    M: Send,

impl Sync for ChannelsOut

impl<M> Sync for OverseerSubsystemContext<M>where
    M: Sync,
    <M as AssociateOutgoing>::OutgoingMessages: Sync,

impl<OutgoingWrapper> Sync for OverseerSender<OutgoingWrapper>where
    OutgoingWrapper: Sync,

impl Sync for AllMessages

impl Sync for HeadData

impl Sync for BlockData

impl Sync for Id

impl Sync for Sibling

impl<Payload, RealPayload> Sync for Signed<Payload, RealPayload>where
    Payload: Sync,
    RealPayload: Sync,

impl<Payload, RealPayload> Sync for UncheckedSigned<Payload, RealPayload>where
    Payload: Sync,
    RealPayload: Sync,

impl<'a> Sync for CounterVecDefinition<'a>

impl<H> Sync for CandidateDescriptor<H>where
    H: Sync,

impl<H> Sync for CandidateReceipt<H>where
    H: Sync,

impl<H, N> Sync for FullCandidateReceipt<H, N>where
    H: Sync,
    N: Sync,

impl<H> Sync for CommittedCandidateReceipt<H>where
    H: Sync,

impl<H, N> Sync for PersistedValidationData<H, N>where
    H: Sync,
    N: Sync,

impl<N> Sync for CandidateCommitments<N>where
    N: Sync,

impl<H> Sync for BackedCandidate<H>where
    H: Sync,

impl Sync for CoreIndex

impl Sync for GroupIndex

impl<N> Sync for GroupRotationInfo<N>where
    N: Sync,

impl<H, N> Sync for OccupiedCore<H, N>where
    H: Sync,
    N: Sync,

impl<H, N> Sync for CoreState<H, N>where
    H: Sync,
    N: Sync,

impl<H> Sync for CandidateEvent<H>where
    H: Sync,

impl<H> Sync for ScrapedOnChainVotes<H>where
    H: Sync,

impl<N> Sync for DisputeState<N>where
    N: Sync,

impl<HDR> Sync for InherentData<HDR>

impl<H> Sync for SigningContext<H>where
    H: Sync,

impl Sync for SessionInfo

impl Sync for BabeDeps

impl<B> Sync for GrandpaDeps<B>where
    B: Send + Sync,

impl Sync for BeefyDeps

impl<C, P, SC, B> Sync for FullDeps<C, P, SC, B>where
    B: Send + Sync,
    C: Send + Sync,
    P: Send + Sync,
    SC: Sync,

impl Sync for DotLocation

impl Sync for Ancestry

impl Sync for Polkadot

impl Sync for XcmConfig

impl Sync for BaseFilter

impl Sync for Version

impl Sync for SS58Prefix

impl Sync for MaxLocks

impl Sync for MaxReserves

impl Sync for SessionKeys

impl Sync for SignedPhase

impl Sync for RewardCurve

impl Sync for MaxVotes

impl Sync for MaxVoters

impl Sync for SpendPeriod

impl Sync for Burn

impl Sync for MaxKeys

impl Sync for MaxRetries

impl Sync for Prefix

impl Sync for DepositBase

impl Sync for MaxProxies

impl Sync for MaxPending

impl Sync for ProxyType

impl Sync for ParaDeposit

impl Sync for LeasePeriod

impl Sync for LeaseOffset

impl Sync for CrowdloanId

impl Sync for Runtime

impl Sync for Event

impl !Sync for Origin

impl Sync for PalletInfo

impl Sync for Call

impl Sync for RuntimeApi

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,

impl<AccountId, LeasePeriod> Sync for ParachainTemporarySlot<AccountId, LeasePeriod>where
    AccountId: Sync,
    LeasePeriod: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,
    <<<T as Config>::Leaser as Leaser<<T as Config>::BlockNumber>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,
    <<<T as Config>::Leaser as Leaser<<T as Config>::BlockNumber>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,
    <<<T as Config>::VestingSchedule as VestingSchedule<<T as Config>::AccountId>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for GenesisConfig<T>where
    <<<T as Config>::VestingSchedule as VestingSchedule<<T as Config>::AccountId>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,

impl<T> Sync for Call<T>where
    T: Sync,
    <<<T as Config>::VestingSchedule as VestingSchedule<<T as Config>::AccountId>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,

impl<T> Sync for PrevalidateAttests<T>

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,
    <<<T as Config>::Auctioneer as Auctioneer<<T as Config>::BlockNumber>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,
    <<<T as Config>::Auctioneer as Auctioneer<<T as Config>::BlockNumber>>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,

impl<BlockNumber> Sync for LastContribution<BlockNumber>where
    BlockNumber: Sync,

impl<AccountId, Balance, BlockNumber, LeasePeriod> Sync for FundInfo<AccountId, Balance, BlockNumber, LeasePeriod>where
    AccountId: Sync,
    Balance: Sync,
    BlockNumber: Sync,
    LeasePeriod: Sync,

impl<R> Sync for ToAuthor<R>where
    R: Sync,

impl<R> Sync for DealWithFees<R>where
    R: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,

impl<Account, Balance> Sync for ParaInfo<Account, Balance>where
    Account: Sync,
    Balance: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,

impl<Balance> Sync for AccountStatus<Balance>where
    Balance: Sync,

impl Sync for SlotRange

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,
    <<T as Config>::Currency as Currency<<T as Config>::AccountId>>::Balance: Sync,

impl Sync for LeaseError

impl<BlockNumber> Sync for AuctionStatus<BlockNumber>where
    BlockNumber: Sync,

impl<T, W> Sync for ChildParachainRouter<T, W>where
    T: Sync,
    W: Sync,

impl Sync for BlockLength

impl<T> Sync for ParachainSessionKeyPlaceholder<T>where
    T: Sync,

impl<T> Sync for AssignmentSessionKeyPlaceholder<T>where
    T: Sync,

impl Sync for WeightToFee

impl Sync for Counter

impl Sync for CounterVec

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for GenesisConfig<T>

impl<T> Sync for Call<T>where
    T: Sync,

impl<BlockNumber> Sync for HostConfiguration<BlockNumber>where
    BlockNumber: Sync,

impl<BlockNumber> Sync for InconsistentError<BlockNumber>where
    BlockNumber: Sync,

impl<BlockNumber> Sync for SessionChangeOutcome<BlockNumber>where
    BlockNumber: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,

impl Sync for HrmpChannel

impl<BlockNumber> Sync for HrmpWatermarkAcceptanceErr<BlockNumber>where
    BlockNumber: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Event<T>where
    T: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,

impl<N> Sync for AvailabilityBitfieldRecord<N>where
    N: Sync,

impl<H, N> Sync for CandidatePendingAvailability<H, N>where
    H: Sync,
    N: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,

impl<BlockNumber> Sync for SessionChangeNotification<BlockNumber>where
    BlockNumber: Sync,

impl Sync for Metrics

impl<T> Sync for Pallet<T>where
    T: Sync,

impl Sync for Origin

impl<T> Sync for Call<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl Sync for Event

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,

impl<N> Sync for ReplacementTimes<N>where
    N: Sync,

impl<N> Sync for ParaPastCodeMeta<N>where
    N: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,

impl<C> Sync for RewardValidatorsWithEraPoints<C>where
    C: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,

impl Sync for FreedReason

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,

impl<T> Sync for Pallet<T>where
    T: Sync,

impl Sync for Event

impl<T> Sync for Error<T>where
    T: Sync,

impl<T> Sync for Call<T>where
    T: Sync,

impl<XcmExecutor, Config> Sync for XcmSink<XcmExecutor, Config>where
    Config: Sync,
    XcmExecutor: Sync,

impl Sync for Extensions

impl<B> Sync for SelectRelayChain<B>

impl<'a, Spawner, RuntimeClient> Sync for OverseerGenArgs<'a, Spawner, RuntimeClient>

impl Sync for Error

impl<C> !Sync for NewFull<C>

impl Sync for IsCollator

impl Sync for Error

impl Sync for FatalError

impl Sync for JfyiError

impl<R> Sync for StatementDistributionSubsystem<R>where
    R: Sync,

impl<Candidate, Digest> Sync for Statement<Candidate, Digest>where
    Candidate: Sync,
    Digest: Sync,

impl<Candidate, Digest, AuthorityId, Signature> Sync for SignedStatement<Candidate, Digest, AuthorityId, Signature>where
    AuthorityId: Sync,
    Candidate: Sync,
    Digest: Sync,
    Signature: Sync,

impl<Candidate, Digest, Signature> Sync for ValidityDoubleVote<Candidate, Digest, Signature>where
    Candidate: Sync,
    Digest: Sync,
    Signature: Sync,

impl<Candidate, Digest, Signature> Sync for DoubleSign<Candidate, Digest, Signature>where
    Candidate: Sync,
    Digest: Sync,
    Signature: Sync,

impl<Candidate, Signature> Sync for MultipleCandidates<Candidate, Signature>where
    Candidate: Sync,
    Signature: Sync,

impl<Candidate, Digest, AuthorityId, Signature> Sync for UnauthorizedStatement<Candidate, Digest, AuthorityId, Signature>where
    AuthorityId: Sync,
    Candidate: Sync,
    Digest: Sync,
    Signature: Sync,

impl<Candidate, Digest, AuthorityId, Signature> Sync for Misbehavior<Candidate, Digest, AuthorityId, Signature>where
    AuthorityId: Sync,
    Candidate: Sync,
    Digest: Sync,
    Signature: Sync,

impl<Digest, Group> Sync for Summary<Digest, Group>where
    Digest: Sync,
    Group: Sync,

impl<Signature> Sync for ValidityAttestation<Signature>where
    Signature: Sync,

impl<Group, Candidate, AuthorityId, Signature> Sync for AttestedCandidate<Group, Candidate, AuthorityId, Signature>where
    AuthorityId: Sync,
    Candidate: Sync,
    Group: Sync,
    Signature: Sync,

impl<Ctx> Sync for CandidateData<Ctx>where
    <Ctx as Context>::AuthorityId: Sync,
    <Ctx as Context>::Candidate: Sync,
    <Ctx as Context>::GroupId: Sync,
    <Ctx as Context>::Signature: Sync,

impl<Ctx> Sync for Table<Ctx>where
    <Ctx as Context>::AuthorityId: Sync,
    <Ctx as Context>::Candidate: Sync,
    <Ctx as Context>::Digest: Sync,
    <Ctx as Context>::GroupId: Sync,
    <Ctx as Context>::Signature: Sync,

impl<'a, Ctx> Sync for DrainMisbehaviors<'a, Ctx>where
    <Ctx as Context>::AuthorityId: Sync,
    <Ctx as Context>::Candidate: Sync,
    <Ctx as Context>::Digest: Sync,
    <Ctx as Context>::Signature: Sync,

impl Sync for Event

impl Sync for Poller

impl Sync for Poly1305

impl Sync for Polyval

impl Sync for YesS3

impl Sync for NoS3

impl Sync for YesS4

impl Sync for NoS4

impl Sync for YesA1

impl Sync for NoA1

impl Sync for YesA2

impl Sync for NoA2

impl Sync for YesNI

impl Sync for NoNI

impl<S3, S4, NI> Sync for SseMachine<S3, S4, NI>where
    NI: Sync,
    S3: Sync,
    S4: Sync,

impl<NI> Sync for Avx2Machine<NI>where
    NI: Sync,

impl Sync for Error

impl Sync for U128

impl Sync for U256

impl Sync for U512

impl Sync for H128

impl Sync for H160

impl Sync for H256

impl Sync for H384

impl Sync for H512

impl Sync for H768

impl Sync for AssetPair

impl<AccountId, Balance, IntentionID> Sync for ExchangeIntention<AccountId, Balance, IntentionID>where
    AccountId: Sync,
    Balance: Sync,
    IntentionID: Sync,

impl<T> Sync for MeteredReceiver<T>where
    T: Send,

impl<T> Sync for MeteredSender<T>where
    T: Send,

impl Sync for Reason

impl Sync for Error

impl<T> Sync for MeteredSender<T>where
    T: Send,

impl<T> Sync for MeteredReceiver<T>where
    T: Send,

impl<T> Sync for OutputWithMeasurements<T>where
    T: Sync,

impl<T> Sync for UnboundedMeteredReceiver<T>where
    T: Send,

impl<T> Sync for UnboundedMeteredSender<T>where
    T: Send,

impl Sync for Meter

impl Sync for Readout

impl<T> Sync for MaybeTimeOfFlight<T>where
    T: Sync,

impl !Sync for IntoIter

impl !Sync for TokenStream

impl !Sync for LexError

impl Sync for LineColumn

impl !Sync for Span

impl !Sync for TokenTree

impl !Sync for Group

impl Sync for Delimiter

impl !Sync for Punct

impl Sync for Spacing

impl !Sync for Ident

impl !Sync for Literal

impl Sync for Error

impl Sync for FoundCrate

impl Sync for Level

impl !Sync for Diagnostic

impl !Sync for SpanRange

impl Sync for LabelPair

impl Sync for Gauge

impl Sync for Counter

impl Sync for Quantile

impl Sync for Summary

impl Sync for Untyped

impl Sync for Histogram

impl Sync for Bucket

impl Sync for Metric

impl Sync for MetricType

impl Sync for AtomicF64

impl Sync for AtomicI64

impl Sync for AtomicU64

impl<T, V, D> Sync for AFLocalCounter<T, V, D>where
    D: Sync,
    T: Send,
    V: Send,

impl<T, D> Sync for AFLocalHistogram<T, D>where
    D: Sync,
    T: Send,

impl<P> Sync for GenericCounter<P>

impl<P> !Sync for GenericLocalCounter<P>

impl Sync for Desc

impl Sync for TextEncoder

impl Sync for Error

impl<P> Sync for GenericGauge<P>

impl Sync for Histogram

impl Sync for Opts

impl Sync for Registry

impl<T> Sync for MetricVec<T>

impl<'a, 'b> !Sync for Encoder<'a, 'b>

impl<'a> !Sync for BucketEncoder<'a>

impl<'a> !Sync for ValueEncoder<'a>

impl<'a> !Sync for ExemplarEncoder<'a>

impl<N, A> Sync for Counter<N, A>where
    A: Send + Sync,
    N: Sync,

impl<S, V> Sync for Exemplar<S, V>where
    S: Sync,
    V: Sync,

impl<S, N, A> Sync for CounterWithExemplar<S, N, A>where
    A: Send + Sync,
    N: Send + Sync,
    S: Send + Sync,

impl<S, N, A> Sync for CounterWithExemplarInner<S, N, A>where
    A: Send + Sync,
    N: Sync,
    S: Sync,

impl<S> Sync for HistogramWithExemplars<S>where
    S: Send + Sync,

impl<S> Sync for HistogramWithExemplarsInner<S>where
    S: Sync,

impl<S, M, C> Sync for Family<S, M, C>where
    C: Sync,
    M: Send + Sync,
    S: Send + Sync,

impl<N, A> Sync for Gauge<N, A>where
    A: Send + Sync,
    N: Sync,

impl Sync for Histogram

impl<S> Sync for Info<S>where
    S: Sync,

impl Sync for MetricType

impl<M> Sync for Registry<M>where
    M: Sync,

impl<'a, M> Sync for RegistryIterator<'a, M>where
    M: Sync,

impl Sync for Descriptor

impl Sync for Unit

impl Sync for DecodeError

impl Sync for EncodeError

impl<In, Out> Sync for Codec<In, Out>where
    In: Sync,
    Out: Sync,

impl Sync for Error

impl<X, E> Sync for Context<X, E>where
    E: Sync,
    X: Sync,

impl<A> Sync for Action<A>where
    A: Sync,

impl<S, F, T, A, E> Sync for SinkImpl<S, F, T, A, E>where
    A: Sync,
    E: Sync,
    F: Sync,
    S: Sync,
    T: Sync,

impl Sync for Bernoulli

impl<D, R, T> Sync for DistIter<D, R, T>where
    D: Sync,
    R: Sync,
    T: Sync,

impl<D, F, T, S> Sync for DistMap<D, F, T, S>where
    D: Sync,
    F: Sync,

impl Sync for Open01

impl<'a, T> Sync for Slice<'a, T>where
    T: Sync,

impl<X> Sync for WeightedIndex<X>where
    X: Sync,
    <X as SampleUniform>::Sampler: Sync,

impl<X> Sync for Uniform<X>where
    <X as SampleUniform>::Sampler: Sync,

impl<X> Sync for UniformInt<X>where
    X: Sync,

impl Sync for UniformChar

impl<X> Sync for UniformFloat<X>where
    X: Sync,

impl<W> Sync for WeightedIndex<W>where
    W: Sync,

impl Sync for Standard

impl<R> Sync for ReadRng<R>where
    R: Sync,

impl Sync for ReadError

impl<R, Rsdr> Sync for ReseedingRng<R, Rsdr>where
    R: Sync,
    Rsdr: Sync,
    <R as BlockRngCore>::Results: Sync,

impl Sync for StepRng

impl Sync for SmallRng

impl Sync for StdRng

impl !Sync for ThreadRng

impl Sync for IndexVec

impl<'a> Sync for IndexVecIter<'a>

impl<'a, S: ?Sized, T> Sync for SliceChooseIter<'a, S, T>where
    S: Sync,
    T: Sync,

impl Sync for ChaCha20Rng

impl Sync for ChaCha12Rng

impl Sync for ChaCha8Core

impl Sync for ChaCha8Rng

impl<R: ?Sized> Sync for BlockRng<R>where
    R: Sync,
    <R as BlockRngCore>::Results: Sync,

impl<R: ?Sized> Sync for BlockRng64<R>where
    R: Sync,
    <R as BlockRngCore>::Results: Sync,

impl Sync for Error

impl Sync for OsRng

impl Sync for Binomial

impl Sync for Error

impl<F> Sync for Cauchy<F>where
    F: Sync,

impl Sync for Error

impl Sync for Exp1

impl<F> Sync for Exp<F>where
    F: Sync,

impl Sync for Error

impl<F> Sync for Frechet<F>where
    F: Sync,

impl Sync for Error

impl<F> Sync for Gamma<F>where
    F: Sync,

impl Sync for Error

impl<F> Sync for ChiSquared<F>where
    F: Sync,

impl<F> Sync for FisherF<F>where
    F: Sync,

impl<F> Sync for StudentT<F>where
    F: Sync,

impl<F> Sync for Beta<F>where
    F: Sync,

impl Sync for BetaError

impl Sync for Geometric

impl Sync for Error

impl<F> Sync for Gumbel<F>where
    F: Sync,

impl Sync for Error

impl Sync for Error

impl Sync for Error

impl<F> Sync for InverseGaussian<F>where
    F: Sync,

impl<F> Sync for Normal<F>where
    F: Sync,

impl Sync for Error

impl<F> Sync for LogNormal<F>where
    F: Sync,

impl Sync for Error

impl<F> Sync for NormalInverseGaussian<F>where
    F: Sync,

impl<F> Sync for Pareto<F>where
    F: Sync,

impl Sync for Error

impl<F> Sync for Pert<F>where
    F: Sync,

impl Sync for PertError

impl<F> Sync for Poisson<F>where
    F: Sync,

impl Sync for Error

impl<F> Sync for SkewNormal<F>where
    F: Sync,

impl Sync for Error

impl<F> Sync for Triangular<F>where
    F: Sync,

impl Sync for UnitBall

impl Sync for UnitCircle

impl Sync for UnitDisc

impl Sync for UnitSphere

impl<F> Sync for Weibull<F>where
    F: Sync,

impl Sync for Error

impl<F> Sync for Zeta<F>where
    F: Sync,

impl Sync for ZetaError

impl<F> Sync for Zipf<F>where
    F: Sync,

impl Sync for ZipfError

impl Sync for Lcg128Xsl64

impl Sync for Mcg128Xsl64

impl Sync for Lcg64Xsh32

impl<T, const N: usize> Sync for IntoIter<T, N>where
    T: Sync,

impl<T> Sync for IntoIter<T>where
    T: Sync,

impl<'a, T> Sync for Iter<'a, T>

impl<'a, T> Sync for Drain<'a, T>where
    T: Sync,

impl<K, V> Sync for IntoIter<K, V>where
    K: Sync,
    V: Sync,

impl<'a, K, V> Sync for Iter<'a, K, V>

impl<'a, K, V> Sync for IterMut<'a, K, V>where
    V: Sync,

impl<T> Sync for IntoIter<T>where
    T: Sync,

impl<'a, T> Sync for Iter<'a, T>

impl<K, V> Sync for IntoIter<K, V>where
    K: Sync,
    V: Sync,

impl<'a, K, V> Sync for Iter<'a, K, V>

impl<'a, K, V> Sync for IterMut<'a, K, V>where
    V: Sync,

impl<'a, K, V> Sync for Drain<'a, K, V>where
    K: Sync,
    V: Sync,

impl<T> Sync for IntoIter<T>where
    T: Sync,

impl<'a, T> Sync for Iter<'a, T>

impl<'a, T> Sync for Drain<'a, T>where
    T: Sync,

impl<T> Sync for IntoIter<T>where
    T: Sync,

impl<'a, T> Sync for Iter<'a, T>

impl<'a, T> Sync for IterMut<'a, T>where
    T: Sync,

impl<T> Sync for IntoIter<T>where
    T: Sync,

impl<'a, T> Sync for Iter<'a, T>

impl<'a, T> Sync for IterMut<'a, T>where
    T: Sync,

impl<'a, T> Sync for Drain<'a, T>where
    T: Sync,

impl<A, B> Sync for Chain<A, B>where
    A: Sync,
    B: Sync,

impl<I> Sync for Chunks<I>where
    I: Sync,

impl<I> Sync for Cloned<I>where
    I: Sync,

impl<I> Sync for Copied<I>where
    I: Sync,

impl<T> Sync for Empty<T>where
    T: Sync,

impl<I> Sync for Enumerate<I>where
    I: Sync,

impl<I, P> Sync for Filter<I, P>where
    I: Sync,
    P: Sync,

impl<I, P> Sync for FilterMap<I, P>where
    I: Sync,
    P: Sync,

impl<I, F> Sync for FlatMap<I, F>where
    F: Sync,
    I: Sync,

impl<I, F> Sync for FlatMapIter<I, F>where
    F: Sync,
    I: Sync,

impl<I> Sync for Flatten<I>where
    I: Sync,

impl<I> Sync for FlattenIter<I>where
    I: Sync,

impl<I, ID, F> Sync for Fold<I, ID, F>where
    F: Sync,
    I: Sync,
    ID: Sync,

impl<I, U, F> Sync for FoldWith<I, U, F>where
    F: Sync,
    I: Sync,
    U: Sync,

impl<I, F> Sync for Inspect<I, F>where
    F: Sync,
    I: Sync,

impl<I, J> Sync for Interleave<I, J>where
    I: Sync,
    J: Sync,

impl<I, J> Sync for InterleaveShortest<I, J>where
    I: Sync,
    J: Sync,

impl<I> Sync for Intersperse<I>where
    I: Sync,
    <I as ParallelIterator>::Item: Sync,

impl<I> Sync for MinLen<I>where
    I: Sync,

impl<I> Sync for MaxLen<I>where
    I: Sync,

impl<I, F> Sync for Map<I, F>where
    F: Sync,
    I: Sync,

impl<I, T, F> Sync for MapWith<I, T, F>where
    F: Sync,
    I: Sync,
    T: Sync,

impl<I, INIT, F> Sync for MapInit<I, INIT, F>where
    F: Sync,
    I: Sync,
    INIT: Sync,

impl<T> Sync for MultiZip<T>where
    T: Sync,

impl<T> Sync for Once<T>where
    T: Sync,

impl<I> Sync for PanicFuse<I>where
    I: Sync,

impl<Iter> Sync for IterBridge<Iter>where
    Iter: Sync,

impl<I, P> Sync for Positions<I, P>where
    I: Sync,
    P: Sync,

impl<T> Sync for Repeat<T>where
    T: Sync,

impl<T> Sync for RepeatN<T>where
    T: Sync,

impl<I> Sync for Rev<I>where
    I: Sync,

impl<I> Sync for Skip<I>where
    I: Sync,

impl<D, S> Sync for Split<D, S>where
    D: Sync,
    S: Sync,

impl<I> Sync for Take<I>where
    I: Sync,

impl<I, U, ID, F> Sync for TryFold<I, U, ID, F>where
    F: Sync,
    I: Sync,
    ID: Sync,
    U: Sync,

impl<I, U, F> Sync for TryFoldWith<I, U, F>where
    F: Sync,
    I: Sync,
    <U as Try>::Output: Sync,

impl<I, F> Sync for Update<I, F>where
    F: Sync,
    I: Sync,

impl<I> Sync for WhileSome<I>where
    I: Sync,

impl<A, B> Sync for Zip<A, B>where
    A: Sync,
    B: Sync,

impl<A, B> Sync for ZipEq<A, B>where
    A: Sync,
    B: Sync,

impl<I> Sync for StepBy<I>where
    I: Sync,

impl<T> Sync for IntoIter<T>where
    T: Sync,

impl<'a, T> Sync for Iter<'a, T>

impl<'a, T> Sync for IterMut<'a, T>where
    T: Sync,

impl<T> Sync for Iter<T>where
    T: Sync,

impl<T> Sync for Iter<T>where
    T: Sync,

impl<T> Sync for IntoIter<T>where
    T: Sync,

impl<'a, T> Sync for Iter<'a, T>

impl<'a, T> Sync for IterMut<'a, T>where
    T: Sync,

impl<'data, T> Sync for Chunks<'data, T>

impl<'data, T> Sync for ChunksExact<'data, T>

impl<'data, T> Sync for ChunksMut<'data, T>where
    T: Sync,

impl<'data, T> Sync for ChunksExactMut<'data, T>where
    T: Sync,

impl<'data, T> Sync for RChunks<'data, T>

impl<'data, T> Sync for RChunksExact<'data, T>

impl<'data, T> Sync for RChunksMut<'data, T>where
    T: Sync,

impl<'data, T> Sync for RChunksExactMut<'data, T>where
    T: Sync,

impl<'data, T> Sync for Iter<'data, T>

impl<'data, T> Sync for Windows<'data, T>

impl<'data, T> Sync for IterMut<'data, T>where
    T: Sync,

impl<'data, T, P> Sync for Split<'data, T, P>where
    P: Sync,
    T: Sync,

impl<'data, T, P> Sync for SplitMut<'data, T, P>where
    P: Sync,
    T: Sync,

impl<'ch> Sync for Chars<'ch>

impl<'ch> Sync for CharIndices<'ch>

impl<'ch> Sync for Bytes<'ch>

impl<'ch> Sync for EncodeUtf16<'ch>

impl<'ch, P> Sync for Split<'ch, P>

impl<'ch, P> Sync for SplitTerminator<'ch, P>

impl<'ch> Sync for Lines<'ch>

impl<'ch> Sync for SplitWhitespace<'ch>

impl<'ch, P> Sync for Matches<'ch, P>

impl<'ch, P> Sync for MatchIndices<'ch, P>

impl<'a> Sync for Drain<'a>

impl<T> Sync for IntoIter<T>where
    T: Sync,

impl<'data, T> Sync for Drain<'data, T>where
    T: Sync,

impl<'scope> Sync for Scope<'scope>

impl<'scope> Sync for ScopeFifo<'scope>

impl Sync for ThreadPool

impl<S = DefaultSpawn> !Sync for ThreadPoolBuilder<S>

impl !Sync for FnContext

impl Sync for Error

impl Sync for Additive

impl Sync for Multiplier

impl Sync for AdditiveFFT

impl Sync for Additive

impl Sync for Multiplier

impl Sync for AdditiveFFT

impl Sync for CodeParams

impl Sync for ReedSolomon

impl !Sync for IndexSet

impl Sync for SetBitsIter

impl Sync for Inst

impl Sync for Block

impl Sync for InstRange

impl<'a, F> Sync for Checker<'a, F>where
    F: Sync,

impl Sync for RegClass

impl Sync for PReg

impl Sync for VReg

impl Sync for SpillSlot

impl Sync for OperandKind

impl Sync for OperandPos

impl Sync for Operand

impl Sync for Allocation

impl Sync for ProgPoint

impl Sync for Edit

impl<'a> Sync for InstOrEdit<'a>

impl<'a> Sync for OutputIter<'a>

impl Sync for MachineEnv

impl Sync for Output

impl<'t> Sync for Match<'t>

impl Sync for Regex

impl<'r, 't> !Sync for Matches<'r, 't>

impl<'r, 't> !Sync for CaptureMatches<'r, 't>

impl<'r, 't> !Sync for Split<'r, 't>

impl<'r, 't> !Sync for SplitN<'r, 't>

impl<'r> Sync for CaptureNames<'r>

impl<'t> Sync for Captures<'t>

impl<'c, 't> Sync for SubCaptureMatches<'c, 't>

impl<'a, R: ?Sized> Sync for ReplacerRef<'a, R>where
    R: Sync,

impl<'t> Sync for NoExpand<'t>

impl Sync for RegexSet

impl Sync for SetMatches

impl<'a> Sync for SetMatchesIter<'a>

impl Sync for Error

impl Sync for RegexSet

impl Sync for SetMatches

impl<'a> Sync for SetMatchesIter<'a>

impl<'t> Sync for Match<'t>

impl Sync for Regex

impl<'r> Sync for CaptureNames<'r>

impl<'r, 't> !Sync for Split<'r, 't>

impl<'r, 't> !Sync for SplitN<'r, 't>

impl<'t> Sync for Captures<'t>

impl<'c, 't> Sync for SubCaptureMatches<'c, 't>

impl<'r, 't> !Sync for CaptureMatches<'r, 't>

impl<'r, 't> !Sync for Matches<'r, 't>

impl<'a, R: ?Sized> Sync for ReplacerRef<'a, R>where
    R: Sync,

impl<'t> Sync for NoExpand<'t>

impl<T, S> Sync for DenseDFA<T, S>where
    S: Sync,
    T: Sync,

impl<T, S> Sync for Standard<T, S>where
    S: Sync,
    T: Sync,

impl<T, S> Sync for ByteClass<T, S>where
    S: Sync,
    T: Sync,

impl<T, S> Sync for Premultiplied<T, S>where
    S: Sync,
    T: Sync,

impl<T, S> Sync for PremultipliedByteClass<T, S>where
    S: Sync,
    T: Sync,

impl Sync for Builder

impl Sync for Error

impl Sync for ErrorKind

impl<D> Sync for Regex<D>where
    D: Sync,

impl<T, S> Sync for SparseDFA<T, S>where
    S: Sync,
    T: Sync,

impl<T, S> Sync for Standard<T, S>where
    S: Sync,
    T: Sync,

impl<T, S> Sync for ByteClass<T, S>where
    S: Sync,
    T: Sync,

impl !Sync for Parser

impl Sync for Printer

impl Sync for Error

impl Sync for ErrorKind

impl Sync for Span

impl Sync for Position

impl Sync for Comment

impl Sync for Ast

impl Sync for Alternation

impl Sync for Concat

impl Sync for Literal

impl Sync for LiteralKind

impl Sync for Class

impl Sync for ClassPerl

impl Sync for ClassAscii

impl Sync for ClassSet

impl Sync for Assertion

impl Sync for Repetition

impl Sync for Group

impl Sync for GroupKind

impl Sync for CaptureName

impl Sync for SetFlags

impl Sync for Flags

impl Sync for FlagsItem

impl Sync for Flag

impl Sync for Error

impl Sync for Literals

impl Sync for Literal

impl Sync for Printer

impl !Sync for Translator

impl Sync for Error

impl Sync for ErrorKind

impl Sync for Hir

impl Sync for HirKind

impl Sync for Literal

impl Sync for Class

impl<'a> Sync for ClassUnicodeIter<'a>

impl Sync for ClassBytes

impl<'a> Sync for ClassBytesIter<'a>

impl Sync for Anchor

impl Sync for Group

impl Sync for GroupKind

impl Sync for Repetition

impl !Sync for Parser

impl Sync for Utf8Range

impl Sync for Error

impl Sync for Protection

impl Sync for RpcService

impl<B> Sync for Mode<B>

impl Sync for Transport

impl<B> Sync for OnlineConfig<B>

impl<B> Sync for Builder<B>

impl Sync for ParseError

impl Sync for Network

impl Sync for ScopedIp

impl Sync for Config

impl<'a> Sync for DomainIter<'a>

impl Sync for Lookup

impl Sync for Family

impl<D> Sync for HmacDrbg<D>where
    D: Sync,

impl Sync for TestCase

impl<'a> Sync for File<'a>

impl Sync for SealingKey

impl Sync for OpeningKey

impl Sync for Nonce

impl Sync for Algorithm

impl<N> Sync for OpeningKey<N>where
    N: Sync,

impl<N> Sync for SealingKey<N>where
    N: Sync,

impl<A> Sync for Aad<A>where
    A: Sync,

impl Sync for UnboundKey

impl Sync for LessSafeKey

impl Sync for Algorithm

impl Sync for Tag

impl Sync for Algorithm

impl Sync for PublicKey

impl<B> Sync for UnparsedPublicKey<B>where
    B: Sync,

impl<'a> Sync for Positive<'a>

impl Sync for Context

impl Sync for Digest

impl Sync for Algorithm

impl Sync for Unspecified

impl Sync for KeyRejected

impl Sync for Algorithm

impl Sync for Salt

impl Sync for Prk

impl<'a, L> Sync for Okm<'a, L>where
    L: Sync,

impl Sync for Algorithm

impl Sync for Tag

impl Sync for Key

impl Sync for Context

impl Sync for Algorithm

impl Sync for Document

impl<T> Sync for Random<T>where
    T: Sync,

impl<B> Sync for RsaPublicKeyComponents<B>where
    B: Sync,

impl Sync for RsaKeyPair

impl Sync for Signature

impl<B> Sync for UnparsedPublicKey<B>where
    B: Sync,

impl !Sync for BackupEngine

impl<'db> !Sync for Checkpoint<'db>

impl !Sync for ColumnFamily

impl<'a> !Sync for BoundColumnFamily<'a>

impl Sync for Decision

impl<F> Sync for CompactionFilterCallback<F>where
    F: Sync,

impl Sync for LiveFile

impl<'a, D> Sync for DBIteratorWithThreadMode<'a, D>

impl Sync for Direction

impl<'a> Sync for IteratorMode<'a>

impl Sync for Cache

impl Sync for Env

impl !Sync for FlushOptions

impl Sync for LogLevel

impl !Sync for DBPath

impl<F, PF> Sync for MergeOperatorCallback<F, PF>

impl<'a> !Sync for MergeOperandsIter<'a>

impl Sync for PerfMetric

impl !Sync for PerfContext

impl !Sync for WriteBatch

impl Sync for Error

impl Sync for RocLocation

impl Sync for Ancestry

impl Sync for Rococo

impl Sync for XcmConfig

impl Sync for SessionKeys

impl Sync for Runtime

impl Sync for Event

impl !Sync for Origin

impl Sync for PalletInfo

impl Sync for Call

impl Sync for BaseFilter

impl Sync for Version

impl Sync for SS58Prefix

impl Sync for SlashPeriod

impl Sync for MaxKeys

impl Sync for MaxLocks

impl Sync for MaxReserves

impl Sync for MaxRetries

impl Sync for ParaDeposit

impl Sync for LeafVersion

impl Sync for LeasePeriod

impl Sync for CrowdloanId

impl Sync for MaxProxies

impl Sync for MaxPending

impl Sync for ProxyType

impl Sync for MaxMembers

impl Sync for DepositBase

impl Sync for RuntimeApi

impl Sync for WeightToFee

impl Sync for Handle

impl Sync for Error

impl Sync for LinkHandle

impl Sync for RouteHandle

impl<T> Sync for RouteAddRequest<T>where
    T: Sync,

impl Sync for IpVersion

impl Sync for RuleHandle

impl<T> Sync for RuleAddRequest<T>where
    T: Sync,

impl Sync for QDiscHandle

impl<'a> Sync for Demangle<'a>

impl Sync for FxHasher

impl<T> Sync for ToHexIter<T>where
    T: Sync,

impl<'a> Sync for FromHexIter<'a>

impl !Sync for Dir

impl Sync for DirEntry

impl Sync for FdFlags

impl Sync for Access

impl Sync for AtFlags

impl Sync for Mode

impl Sync for OFlags

impl Sync for RenameFlags

impl Sync for FileType

impl Sync for Advice

impl Sync for MemfdFlags

impl Sync for SealFlags

impl Sync for StatxFlags

impl Sync for StatVfs

impl Sync for Errno

impl Sync for PollFlags

impl<'fd> Sync for PollFd<'fd>

impl Sync for DupFlags

impl Sync for PipeFlags

impl Sync for CreateFlags

impl Sync for EventFlags

impl<'a, T> Sync for Ref<'a, T>where
    T: Sync,

impl<'a> Sync for Borrowing<'a>

impl<'context, T> Sync for Owning<'context, T>where
    T: Sync,

impl<Context> Sync for Epoll<Context>where
    Context: Sync,

impl<'context, Context> !Sync for Iter<'context, Context>

impl<'context, Context> !Sync for EventVec<'context, Context>

impl Sync for ProtFlags

impl Sync for MapFlags

impl Sync for MremapFlags

impl Sync for MsyncFlags

impl Sync for MlockFlags

impl Sync for Advice

impl Sync for Timestamps

impl Sync for OwnedFd

impl Sync for Payload

impl Sync for PayloadU24

impl Sync for PayloadU16

impl Sync for PayloadU8

impl<'a> Sync for Reader<'a>

impl Sync for u24

impl Sync for Compression

impl Sync for ContentType

impl Sync for AlertLevel

impl Sync for NamedCurve

impl Sync for NamedGroup

impl Sync for ECCurveType

impl Sync for Random

impl Sync for SessionID

impl Sync for ServerName

impl Sync for Message

impl<'a> Sync for BorrowedPlainMessage<'a>

impl<T> Sync for Retrieved<T>where
    T: Sync,

impl Sync for Connection

impl Sync for IoState

impl<'a> Sync for Reader<'a>

impl<'a> !Sync for Writer<'a>

impl<Data> Sync for ConnectionCommon<Data>where
    Data: Sync,

impl Sync for CommonState

impl Sync for Error

impl<'a, C: ?Sized, T: ?Sized> Sync for Stream<'a, C, T>where
    C: Sync,
    T: Sync,

impl<C, T> Sync for StreamOwned<C, T>where
    C: Sync,
    T: Sync,

impl<Side, State> Sync for ConfigBuilder<Side, State>where
    Side: Sync,
    State: Sync,

impl Sync for CipherSuite

impl Sync for PrivateKey

impl Sync for Certificate

impl Sync for NoKeyLog

impl Sync for KeyLogFile

impl Sync for Ticketer

impl Sync for ServerName

impl<'a> Sync for WriteEarlyData<'a>

impl<'a> Sync for ClientHello<'a>

impl<'a> Sync for ReadEarlyData<'a>

impl Sync for Acceptor

impl Sync for Accepted

impl Sync for SignError

impl Sync for Certificate

impl Sync for Item

impl<S> Sync for RwStreamSink<S>where
    S: Sync,
    <S as TryStream>::Ok: Sync,

impl Sync for Buffer

impl<R> Sync for XSalsaCore<R>where
    R: Sync,

impl<R> Sync for SalsaCore<R>where
    R: Sync,

impl Sync for Error

impl Sync for Service

impl Sync for Role

impl<Client, Network, Block, DhtEventStream> Sync for Worker<Client, Network, Block, DhtEventStream>where
    Block: Sync,
    Client: Send + Sync,
    DhtEventStream: Sync,
    Network: Send + Sync,

impl<A, B, C, PR> Sync for ProposerFactory<A, B, C, PR>where
    A: Send + Sync,
    B: Sync,
    C: Send + Sync,
    PR: Sync,

impl<B, Block, C, A, PR> Sync for Proposer<B, Block, C, A, PR>where
    B: Sync,
    C: Send + Sync,
    PR: Sync,

impl Sync for RecordProof

impl<Block, StateBackend> Sync for BuiltBlock<Block, StateBackend>where
    <StateBackend as Backend<<<Block as Block>::Header as Header>::Hashing>>::Transaction: Sync,

impl<'a, Block, A, B> Sync for BlockBuilder<'a, Block, A, B>where
    B: Sync,
    <A as ProvideRuntimeApi<Block>>::Api: Sync,

impl<G, E> Sync for ChainSpec<G, E>where
    E: Sync,

impl<BlockNumber, T> Sync for Forks<BlockNumber, T>where
    BlockNumber: Sync,
    T: Sync,
    <T as Group>::Fork: Sync,

impl Sync for ChainType

impl Sync for NodeKeyType

impl Sync for OutputType

impl Sync for RpcMethods

impl Sync for Database

impl Sync for SyncMode

impl Sync for GenerateCmd

impl Sync for RevertCmd

impl Sync for RunCmd

impl Sync for SignCmd

impl Sync for VanityCmd

impl Sync for VerifyCmd

impl Sync for Error

impl<C> Sync for Runner<C>where
    C: Sync,

impl<Block> Sync for ImportSummary<Block>

impl<Block> Sync for FinalizeSummary<Block>

impl<Block, B> Sync for ClientImportOperation<Block, B>where
    <B as Backend<Block>>::BlockImportOperation: Sync,

impl<'a, State, Block> Sync for KeyIterator<'a, State, Block>where
    Block: Sync,
    State: Sync,

impl<Block> Sync for ClientInfo<Block>

impl Sync for MemorySize

impl Sync for MemoryInfo

impl Sync for IoInfo

impl Sync for UsageInfo

impl<Block> Sync for BlockImportNotification<Block>

impl<Block> Sync for FinalityNotification<Block>

impl<Block> Sync for ExecutionExtensions<Block>

impl<Block> Sync for Blockchain<Block>

impl<Block> Sync for BlockImportOperation<Block>

impl<Block> Sync for Backend<Block>

impl<H, N> Sync for ImportOutcome<H, N>where
    H: Sync,
    N: Sync,

impl<H, N> Sync for RemoveOutcome<H, N>where
    H: Sync,
    N: Sync,

impl<H, N> Sync for FinalizationOutcome<H, N>where
    H: Sync,
    N: Sync,

impl<H, N> Sync for LeafSet<H, N>where
    H: Sync,
    N: Sync,

impl<'a, H, N> Sync for Undo<'a, H, N>where
    H: Sync,
    N: Sync,

impl<Hash> Sync for StorageNotification<Hash>where
    Hash: Sync,

impl<Block> Sync for StorageNotifications<Block>

impl<H> Sync for StorageEventStream<H>where
    H: Send,

impl<B> !Sync for BenchmarkingState<B>

impl<Block> Sync for RefTrackingState<Block>

impl<Block> Sync for BlockchainDb<Block>

impl<Block> !Sync for BlockImportOperation<Block>

impl<Block> Sync for Backend<Block>

impl Sync for ImportedAux

impl<Block> Sync for BlockCheckParams<Block>

impl<Block, Transaction> Sync for StorageChanges<Block, Transaction>where
    Transaction: Sync,

impl<B> Sync for ImportedState<B>

impl<Block, Transaction> Sync for StateAction<Block, Transaction>where
    Transaction: Sync,

impl<Block, Transaction> !Sync for BlockImportParams<Block, Transaction>

impl<B, Transaction> Sync for BasicQueue<B, Transaction>where
    Transaction: Sync,

impl<B> Sync for BufferedLinkSender<B>

impl<B> Sync for BufferedLinkReceiver<B>

impl<B> Sync for IncomingBlock<B>

impl<N> Sync for BlockImportStatus<N>where
    N: Sync,

impl<B, Block> Sync for LongestChain<B, Block>where
    B: Send + Sync,
    Block: Sync,

impl<T> Sync for SharedDataLockedUpgradable<T>where
    T: Send,

impl<'a, T> Sync for SharedDataLocked<'a, T>where
    T: Send + Sync,

impl<T> Sync for SharedData<T>where
    T: Send,

impl<C, P, CAW, CIDP> Sync for AuraVerifier<C, P, CAW, CIDP>where
    C: Send + Sync,
    CAW: Sync,
    CIDP: Sync,
    P: Sync,

impl<'a, Block, I, C, S, CAW, CIDP> Sync for ImportQueueParams<'a, Block, I, C, S, CAW, CIDP>where
    C: Send + Sync,
    CAW: Sync,
    CIDP: Sync,
    I: Sync,
    S: Sync,

impl<C, CIDP, CAW> Sync for BuildVerifierParams<C, CIDP, CAW>where
    C: Send + Sync,
    CAW: Sync,
    CIDP: Sync,

impl<C, SC, I, PF, SO, L, CIDP, BS, CAW> Sync for StartAuraParams<C, SC, I, PF, SO, L, CIDP, BS, CAW>where
    BS: Sync,
    C: Send + Sync,
    CAW: Sync,
    CIDP: Sync,
    I: Sync,
    L: Sync,
    PF: Sync,
    SC: Sync,
    SO: Sync,

impl<C, I, PF, SO, L, BS> Sync for BuildAuraWorkerParams<C, I, PF, SO, L, BS>where
    BS: Sync,
    C: Send + Sync,
    I: Sync,
    L: Sync,
    PF: Sync,
    SO: Sync,

impl<B> Sync for Error<B>

impl Sync for Epoch

impl<B> Sync for Error<B>

impl<B> Sync for BabeIntermediate<B>

impl<B, C, SC, E, I, SO, L, CIDP, BS, CAW> Sync for BabeParams<B, C, SC, E, I, SO, L, CIDP, BS, CAW>where
    BS: Sync,
    C: Send + Sync,
    CAW: Sync,
    CIDP: Sync,
    E: Sync,
    I: Sync,
    L: Sync,
    SC: Sync,
    SO: Sync,

impl<B> Sync for BabeRequest<B>

impl<B> Sync for BabeWorkerHandle<B>

impl<B> !Sync for BabeWorker<B>

impl<Block> Sync for BabeLink<Block>

impl<Block, Client, SelectChain, CAW, CIDP> Sync for BabeVerifier<Block, Client, SelectChain, CAW, CIDP>where
    CAW: Sync,
    CIDP: Sync,
    Client: Send + Sync,
    SelectChain: Sync,

impl<Block, Client, I> Sync for BabeBlockImport<Block, Client, I>where
    Client: Send + Sync,
    I: Sync,

impl<B, C, SC> Sync for Babe<B, C, SC>where
    C: Send + Sync,
    SC: Sync,

impl Sync for Error

impl<Hash, Number, E> Sync for EpochChangesV0<Hash, Number, E>where
    E: Sync,
    Hash: Sync,
    Number: Sync,

impl<Hash, Number, E> Sync for EpochChangesV1<Hash, Number, E>where
    E: Sync,
    Hash: Sync,
    Number: Sync,
    <E as Epoch>::Slot: Sync,

impl<H, Block> Sync for HeaderBackendDescendentBuilder<H, Block>where
    Block: Sync,
    H: Sync,

impl<E> Sync for EpochHeader<E>where
    <E as Epoch>::Slot: Sync,

impl<Hash, Number> Sync for EpochIdentifier<Hash, Number>where
    Hash: Sync,
    Number: Sync,

impl<E, ERef> Sync for ViableEpoch<E, ERef>where
    E: Sync,
    ERef: Sync,

impl<Hash, Number, E> Sync for ViableEpochDescriptor<Hash, Number, E>where
    Hash: Sync,
    Number: Sync,
    <E as Epoch>::Slot: Sync,

impl<E> Sync for PersistedEpoch<E>where
    E: Sync,

impl<E> Sync for PersistedEpochHeader<E>where
    <E as Epoch>::Slot: Sync,

impl<E> Sync for IncrementedEpoch<E>where
    E: Sync,

impl<Hash, Number, E> Sync for GapEpochs<Hash, Number, E>where
    E: Sync,
    Hash: Sync,
    Number: Sync,

impl<Hash, Number, E> Sync for EpochChanges<Hash, Number, E>where
    E: Sync,
    Hash: Sync,
    Number: Sync,
    <E as Epoch>::Slot: Sync,

impl<B> Sync for SlotInfo<B>

impl<Block, Proof> Sync for SlotResult<Block, Proof>where
    Proof: Sync,

impl<T> Sync for SimpleSlotWorkerToSlotWorker<T>where
    T: Sync,

impl<H, S> Sync for CheckedHeader<H, S>where
    H: Sync,
    S: Sync,

impl<N> Sync for BackoffAuthoringOnFinalizedHeadLagging<N>where
    N: Sync,

impl<H> Sync for WasmExecutor<H>where
    H: Sync,

impl Sync for Error

impl Sync for WasmError

impl Sync for Backtrace

impl<Global> Sync for GlobalsSnapshot<Global>where
    Global: Sync,

impl Sync for RuntimeBlob

impl<'a> !Sync for GuestExternals<'a>

impl !Sync for Memory

impl<DT> !Sync for Store<DT>

impl<'a> Sync for InvokeMethod<'a>

impl Sync for Semantics

impl Sync for Config

impl<H, N> Sync for SharedAuthoritySet<H, N>where
    H: Send,
    N: Send,

impl<H, N> Sync for AuthoritySet<H, N>where
    H: Sync,
    N: Sync,

impl<N> Sync for AuthoritySetChanges<N>where
    N: Sync,

impl<BE, Block> Sync for FinalityProofProvider<BE, Block>where
    BE: Send + Sync,

impl<Header> Sync for FinalityProof<Header>

impl<Backend, Block, Client, SC> Sync for GrandpaBlockImport<Backend, Block, Client, SC>where
    Backend: Sync,
    Client: Send + Sync,
    SC: Sync,

impl<Block> Sync for GrandpaJustification<Block>

impl<N> Sync for BeforeBestBlockBy<N>where
    N: Sync,

impl<Block, B> Sync for VotingRulesBuilder<Block, B>

impl Sync for Error

impl<Block> Sync for WarpSyncFragment<Block>

impl<Block> Sync for WarpSyncProof<Block>

impl<Block, Backend> Sync for NetworkProvider<Block, Backend>

impl Sync for Config

impl Sync for Error

impl<Block, C, SC> Sync for LinkHalf<Block, C, SC>where
    C: Send + Sync,
    SC: Sync,

impl<Block> Sync for AuthoritySetHardFork<Block>

impl<Block, C, N, SC, VR> Sync for GrandpaParams<Block, C, N, SC, VR>where
    C: Send + Sync,
    N: Sync,
    SC: Sync,
    VR: Sync,

impl<AuthoritySet, VoterState, Block, ProofProvider> Sync for Grandpa<AuthoritySet, VoterState, Block, ProofProvider>where
    AuthoritySet: Sync,
    ProofProvider: Send + Sync,
    VoterState: Sync,

impl Sync for Error

impl<B> Sync for PeerInfo<B>

impl<B, H> Sync for NetworkService<B, H>

impl<'a> Sync for NotificationSenderReady<'a>

impl<B, H, Client> !Sync for NetworkWorker<B, H, Client>

impl<Block> Sync for Bitswap<Block>

impl<B, H, Client> !Sync for Params<B, H, Client>

impl Sync for Role

impl Sync for SyncMode

impl Sync for SetConfig

impl<K> Sync for Secret<K>where
    K: Sync,

impl Sync for Error

impl Sync for Peer

impl Sync for Endpoint

impl<B, H> !Sync for TransactionsHandler<B, H>

impl Sync for ProtocolId

impl Sync for ParseErr

impl Sync for DhtEvent

impl Sync for Event

impl Sync for Signature

impl<B> Sync for NetworkStatus<B>

impl<Header, Hash, Extrinsic> Sync for BlockData<Header, Hash, Extrinsic>where
    Extrinsic: Sync,
    Hash: Sync,
    Header: Sync,

impl<Hash, Number> Sync for BlockRequest<Hash, Number>where
    Hash: Sync,
    Number: Sync,

impl<Hash, Number> Sync for FromBlock<Hash, Number>where
    Hash: Sync,
    Number: Sync,

impl<Header, Hash, Extrinsic> Sync for BlockResponse<Header, Hash, Extrinsic>where
    Extrinsic: Sync,
    Hash: Sync,
    Header: Sync,

impl<H> Sync for BlockAnnounce<H>where
    H: Sync,

impl Sync for Direction

impl Sync for BlockState

impl<H> Sync for AnnouncementSummary<H>

impl Sync for Metrics

impl<B> Sync for WarpProofRequest<B>

impl<Block> Sync for VerificationResult<Block>

impl<Block> Sync for WarpSyncPhase<Block>

impl<Block> Sync for WarpSyncProgress<Block>

impl<Block> Sync for PeerInfo<Block>

impl Sync for SyncState

impl<Block> Sync for SyncStatus<Block>

impl Sync for BadPeer

impl<Block> Sync for OnBlockData<Block>

impl<Block> Sync for OnBlockJustification<Block>

impl<Block> Sync for OnStateData<Block>

impl<H> Sync for PollBlockAnnounceValidation<H>where
    H: Sync,

impl Sync for SyncMode

impl Sync for Metrics

impl<B> !Sync for GossipEngine<B>

impl<H> Sync for ValidationResult<H>where
    H: Sync,

impl Sync for DiscardAll

impl<B, Client> Sync for LightClientRequestHandler<B, Client>where
    B: Sync,
    Client: Send + Sync,

impl<B, Client> Sync for BlockRequestHandler<B, Client>where
    Client: Send + Sync,

impl<B> Sync for BlockData<B>

impl<B> Sync for BlockCollection<B>

impl<B, Client> Sync for StateSync<B, Client>where
    Client: Send + Sync,

impl<B> Sync for ImportResult<B>

impl<B, Client> Sync for StateRequestHandler<B, Client>where
    Client: Send + Sync,

impl<B, Client> Sync for WarpSync<B, Client>where
    Client: Send + Sync,

impl<TBlock> Sync for RequestHandler<TBlock>

impl<B, Client> !Sync for ChainSync<B, Client>

impl<B> Sync for PeerSync<B>

impl<B> Sync for PeerSyncState<B>

impl<B> Sync for AncestorSearchState<B>

impl<Storage> Sync for Db<Storage>where
    Storage: Sync,

impl<Client, Block> Sync for OffchainWorkers<Client, Block>where
    Client: Send + Sync,

impl Sync for SetId

impl Sync for Message

impl Sync for SetConfig

impl Sync for Peerset

impl Sync for DropReason

impl Sync for MetricsLink

impl Sync for Metrics

impl<P, Client> Sync for Author<P, Client>where
    Client: Send + Sync,
    P: Send + Sync,

impl<Block, Client> Sync for Chain<Block, Client>

impl<Block, Client> Sync for Dev<Block, Client>where
    Client: Send + Sync,

impl<T> Sync for Offchain<T>

impl<Block, Client> Sync for State<Block, Client>

impl<Block, Client> Sync for ChildState<Block, Client>

impl<B> Sync for System<B>

impl<B> Sync for Request<B>

impl Sync for DenyUnsafe

impl Sync for Error

impl<Hash> Sync for ExtrinsicOrHash<Hash>where
    Hash: Sync,

impl Sync for Error

impl !Sync for Error

impl Sync for BlockStats

impl Sync for Error

impl Sync for Error

impl<Hash> Sync for ReadProof<Hash>where
    Hash: Sync,

impl Sync for Error

impl Sync for SystemInfo

impl Sync for Health

impl<Hash, Number> Sync for PeerInfo<Hash, Number>where
    Hash: Sync,
    Number: Sync,

impl Sync for NodeRole

impl<Number> Sync for SyncState<Number>where
    Number: Sync,

impl Sync for RpcMetrics

impl Sync for WsConfig

impl Sync for TaskType

impl Sync for RpcMethods

impl Sync for BasePath

impl Sync for Error

impl<'a, TBl, TCl, TExPool, TRpc, Backend> !Sync for SpawnTasksParams<'a, TBl, TCl, TExPool, TRpc, Backend>

impl<'a, TBl, TExPool, TImpQu, TCl> !Sync for BuildNetworkParams<'a, TBl, TExPool, TImpQu, TCl>

impl<Block, B, E> Sync for LocalCallExecutor<Block, B, E>where
    B: Send + Sync,
    E: Sync,

impl<Block> Sync for ClientConfig<Block>

impl !Sync for TaskManager

impl Sync for RpcHandlers

impl<Client, Backend, SelectChain, ImportQueue, TransactionPool, Other> !Sync for PartialComponents<Client, Backend, SelectChain, ImportQueue, TransactionPool, Other>

impl<C, P> Sync for TransactionPoolAdapter<C, P>where
    C: Send + Sync,
    P: Send + Sync,

impl<E> Sync for Error<E>where
    E: Sync,

impl Sync for PinError

impl<H> Sync for ChangeSet<H>

impl<H> Sync for CommitSet<H>

impl Sync for Constraints

impl Sync for PruningMode

impl<BlockHash, Key, D> Sync for StateDbSync<BlockHash, Key, D>where
    D: Sync,

impl<BlockHash, Key, D> Sync for StateDb<BlockHash, Key, D>where
    D: Send + Sync,

impl Sync for IsPruned

impl<Block> Sync for Error<Block>

impl<Block> Sync for LightSyncState<Block>

impl<Block, Client> Sync for SyncState<Block, Client>where
    Client: Send + Sync,

impl Sync for HwBench

impl Sync for Error

impl Sync for SysInfo

impl Sync for Telemetry

impl Sync for Error

impl<Block, Client> Sync for BlockExecutor<Block, Client>where
    Client: Send + Sync,

impl<T> Sync for EventFormat<T>where
    T: Sync,

impl Sync for PrefixLayer

impl Sync for Error

impl Sync for TraceEvent

impl Sync for SpanDatum

impl Sync for Values

impl<Client, Block> Sync for FullChainApi<Client, Block>where
    Block: Sync,
    Client: Send + Sync,

impl Sync for Error

impl Sync for Options

impl<B> Sync for Pool<B>

impl<Hash, Ex, Error> Sync for ValidatedTransaction<Hash, Ex, Error>where
    Error: Sync,
    Ex: Sync,
    Hash: Sync,

impl<Hash, Extrinsic> Sync for Transaction<Hash, Extrinsic>where
    Extrinsic: Sync,
    Hash: Sync,

impl Sync for Limit

impl<PoolApi, Block> Sync for BasicPool<PoolApi, Block>

impl Sync for Error

impl Sync for PoolStatus

impl<Hash, BlockHash> Sync for TransactionStatus<Hash, BlockHash>where
    BlockHash: Sync,
    Hash: Sync,

impl<B> Sync for ChainEvent<B>

impl Sync for IDSequence

impl Sync for SeqID

impl<T> Sync for TracingUnboundedSender<T>where
    T: Send,

impl<T> Sync for TracingUnboundedReceiver<T>where
    T: Send,

impl<Payload, TK> Sync for NotificationStream<Payload, TK>where
    Payload: Send,
    TK: Sync,

impl<Payload> Sync for NotificationReceiver<Payload>where
    Payload: Send,

impl<Payload> Sync for NotificationSender<Payload>where
    Payload: Send,

impl<M, R> Sync for Hub<M, R>where
    M: Send,
    R: Send,

impl<M, R> Sync for Receiver<M, R>where
    M: Send,
    R: Send,

impl<T> Sync for StatusSinks<T>where
    T: Send,

impl<'a, T> Sync for ReadySinkEvent<'a, T>where
    T: Send,

impl Sync for SecretKey

impl Sync for PublicKey

impl Sync for Keypair

impl<H> Sync for XoFTranscript<H>where
    H: Sync,

impl<T, R> !Sync for SigningTranscriptWithRng<T, R>

impl Sync for Signature

impl<T> Sync for Malleable<T>where
    T: Sync,

impl Sync for VRFOutput

impl Sync for VRFInOut

impl Sync for VRFProof

impl Sync for ChainCode

impl<K> Sync for ExtendedKey<K>where
    K: Sync,

impl<'a, K> Sync for AggregatePublicKeySlice<'a, K>where
    K: Sync,

impl Sync for Commitment

impl Sync for Reveal

impl<T, S> Sync for MuSig<T, S>where
    S: Sync,
    T: Sync,

impl<K> Sync for CommitStage<K>where
    K: Sync,

impl<K> Sync for RevealStage<K>where
    K: Sync,

impl Sync for CosignStage

impl Sync for Cosignature

impl Sync for Always

impl<'a> Sync for Log<'a>

impl Sync for Error

impl<Size> Sync for EncodedPoint<Size>

impl<'a, Size> Sync for Coordinates<'a, Size>

impl Sync for Tag

impl Sync for Error

impl<'a> Sync for EcPrivateKey<'a>

impl Sync for SignOnly

impl Sync for VerifyOnly

impl Sync for All

impl<'buf> Sync for SignOnlyPreallocated<'buf>

impl<'buf> Sync for VerifyOnlyPreallocated<'buf>

impl<'buf> Sync for AllPreallocated<'buf>

impl Sync for SecretKey

impl Sync for PublicKey

impl Sync for KeyPair

impl Sync for Parity

impl Sync for IntoIter

impl Sync for RecoveryId

impl Sync for Signature

impl Sync for Scalar

impl Sync for Signature

impl Sync for Message

impl Sync for Error

impl Sync for AlignedType

impl Sync for Context

impl Sync for PublicKey

impl Sync for Signature

impl Sync for KeyPair

impl<S> Sync for Secret<S>where
    S: Sync,

impl Sync for Error

impl<E> Sync for UnitDeserializer<E>where
    E: Sync,

impl<E> Sync for BoolDeserializer<E>where
    E: Sync,

impl<E> Sync for I8Deserializer<E>where
    E: Sync,

impl<E> Sync for I16Deserializer<E>where
    E: Sync,

impl<E> Sync for I32Deserializer<E>where
    E: Sync,

impl<E> Sync for I64Deserializer<E>where
    E: Sync,

impl<E> Sync for IsizeDeserializer<E>where
    E: Sync,

impl<E> Sync for U8Deserializer<E>where
    E: Sync,

impl<E> Sync for U16Deserializer<E>where
    E: Sync,

impl<E> Sync for U64Deserializer<E>where
    E: Sync,

impl<E> Sync for UsizeDeserializer<E>where
    E: Sync,

impl<E> Sync for F32Deserializer<E>where
    E: Sync,

impl<E> Sync for F64Deserializer<E>where
    E: Sync,

impl<E> Sync for CharDeserializer<E>where
    E: Sync,

impl<E> Sync for I128Deserializer<E>where
    E: Sync,

impl<E> Sync for U128Deserializer<E>where
    E: Sync,

impl<E> Sync for U32Deserializer<E>where
    E: Sync,

impl<'a, E> Sync for StrDeserializer<'a, E>where
    E: Sync,

impl<'de, E> Sync for BorrowedStrDeserializer<'de, E>where
    E: Sync,

impl<E> Sync for StringDeserializer<E>where
    E: Sync,

impl<'a, E> Sync for CowStrDeserializer<'a, E>where
    E: Sync,

impl<'a, E> Sync for BytesDeserializer<'a, E>where
    E: Sync,

impl<'de, E> Sync for BorrowedBytesDeserializer<'de, E>where
    E: Sync,

impl<I, E> Sync for SeqDeserializer<I, E>where
    E: Sync,
    I: Sync,

impl<A> Sync for SeqAccessDeserializer<A>where
    A: Sync,

impl<'de, I, E> Sync for MapDeserializer<'de, I, E>where
    E: Sync,
    I: Sync,
    <<I as Iterator>::Item as Pair>::Second: Sync,

impl<A> Sync for MapAccessDeserializer<A>where
    A: Sync,

impl<A> Sync for EnumAccessDeserializer<A>where
    A: Sync,

impl Sync for IgnoredAny

impl<'a> Sync for Unexpected<'a>

impl<Ok, Error> Sync for Impossible<Ok, Error>where
    Error: Sync,
    Ok: Sync,

impl<'a> Sync for SliceRead<'a>

impl<'a> Sync for StrRead<'a>

impl<R> Sync for IoRead<R>where
    R: Sync,

impl<R> Sync for Deserializer<R>where
    R: Sync,

impl<'de, R, T> Sync for StreamDeserializer<'de, R, T>where
    R: Sync,
    T: Sync,

impl Sync for Error

impl Sync for Category

impl<K, V> Sync for Map<K, V>where
    K: Sync,
    V: Sync,

impl<'a> Sync for Entry<'a>

impl<'a> Sync for VacantEntry<'a>

impl<'a> Sync for OccupiedEntry<'a>

impl<'a> Sync for Iter<'a>

impl<'a> Sync for IterMut<'a>

impl Sync for IntoIter

impl<'a> Sync for Keys<'a>

impl<'a> Sync for Values<'a>

impl<'a> Sync for ValuesMut<'a>

impl<W, F> Sync for Serializer<W, F>where
    F: Sync,
    W: Sync,

impl Sync for CharEscape

impl<'a> Sync for PrettyFormatter<'a>

impl Sync for Serializer

impl Sync for Number

impl Sync for RawValue

impl Sync for Value

impl Sync for Sha1

impl<'a, T, C = DefaultConfig> !Sync for Ref<'a, T, C>

impl<'a, T, C = DefaultConfig> !Sync for RefMut<'a, T, C>

impl<'a, T, C = DefaultConfig> !Sync for Entry<'a, T, C>

impl<'a, T, C = DefaultConfig> !Sync for VacantEntry<'a, T, C>

impl Sync for Handle

impl<R, E> Sync for SignalDelivery<R, E>where
    R: Sync,

impl<E> Sync for Pending<E>

impl<O> Sync for PollResult<O>where
    O: Sync,

impl<SD, E> Sync for SignalIterator<SD, E>where
    SD: Sync,

impl Sync for SignalOnly

impl<E> Sync for SignalsInfo<E>

impl<'a, E> Sync for Forever<'a, E>

impl Sync for SigId

impl Sync for Error

impl<N> Sync for AutoSimd<N>where
    N: Sync,

impl<N> Sync for AutoBoolSimd<N>where
    N: Sync,

impl<V> Sync for SimdOption<V>where
    V: Sync,
    <V as SimdValue>::SimdBool: Sync,

impl<T> Sync for Slab<T>where
    T: Sync,

impl<'a, T> Sync for VacantEntry<'a, T>where
    T: Sync,

impl<T> Sync for IntoIter<T>where
    T: Sync,

impl<'a, T> Sync for Iter<'a, T>where
    T: Sync,

impl<'a, T> Sync for IterMut<'a, T>where
    T: Sync,

impl<'a, T> Sync for Drain<'a, T>where
    T: Sync,

impl<'a, T> Sync for LinearGroup<'a, T>where
    T: Sync,

impl<'a, T> Sync for LinearGroupMut<'a, T>where
    T: Sync,

impl<'a, T, P> Sync for LinearGroupBy<'a, T, P>where
    P: Sync,
    T: Sync,

impl<'a, T, P> Sync for LinearGroupByMut<'a, T, P>where
    P: Sync,
    T: Sync,

impl<'a, T, F> !Sync for LinearGroupByKey<'a, T, F>

impl<'a, T, F> !Sync for LinearGroupByKeyMut<'a, T, F>

impl<'a, T> !Sync for BinaryGroup<'a, T>

impl<'a, T> !Sync for BinaryGroupMut<'a, T>

impl<'a, T, P> !Sync for BinaryGroupBy<'a, T, P>

impl<'a, T, P> !Sync for BinaryGroupByMut<'a, T, P>

impl<'a, T, F> !Sync for BinaryGroupByKey<'a, T, F>

impl<'a, T, F> !Sync for BinaryGroupByKeyMut<'a, T, F>

impl<'a, T> !Sync for ExponentialGroup<'a, T>

impl<'a, T> !Sync for ExponentialGroupMut<'a, T>

impl<'a, T, P> !Sync for ExponentialGroupBy<'a, T, P>

impl<'a, T, P> !Sync for ExponentialGroupByMut<'a, T, P>

impl<'a, T, F> !Sync for ExponentialGroupByKey<'a, T, F>

impl<'a, T, F> !Sync for ExponentialGroupByKeyMut<'a, T, F>

impl<'a> Sync for LinearStrGroup<'a>

impl<'a> Sync for LinearStrGroupMut<'a>

impl<'a, P> Sync for LinearStrGroupBy<'a, P>where
    P: Sync,

impl<'a, P> Sync for LinearStrGroupByMut<'a, P>where
    P: Sync,

impl<'a, F> Sync for LinearStrGroupByKey<'a, F>where
    F: Sync,

impl<'a, F> Sync for LinearStrGroupByKeyMut<'a, F>where
    F: Sync,

impl<K, V> Sync for SlotMap<K, V>where
    V: Sync,

impl<'a, K, V> Sync for Drain<'a, K, V>where
    V: Sync,

impl<K, V> Sync for IntoIter<K, V>where
    V: Sync,

impl<'a, K, V> Sync for Iter<'a, K, V>where
    V: Sync,

impl<'a, K, V> Sync for IterMut<'a, K, V>where
    V: Sync,

impl<'a, K, V> Sync for Keys<'a, K, V>where
    V: Sync,

impl<'a, K, V> Sync for Values<'a, K, V>where
    V: Sync,

impl<'a, K, V> Sync for ValuesMut<'a, K, V>where
    V: Sync,

impl<K, V> Sync for DenseSlotMap<K, V>where
    K: Sync,
    V: Sync,

impl<'a, K, V> Sync for Drain<'a, K, V>where
    K: Sync,
    V: Sync,

impl<K, V> Sync for IntoIter<K, V>where
    K: Sync,
    V: Sync,

impl<'a, K, V> Sync for Iter<'a, K, V>where
    K: Sync,
    V: Sync,

impl<'a, K, V> Sync for IterMut<'a, K, V>where
    K: Sync,
    V: Sync,

impl<'a, K, V> Sync for Keys<'a, K, V>where
    K: Sync,
    V: Sync,

impl<'a, K, V> Sync for Values<'a, K, V>where
    K: Sync,
    V: Sync,

impl<'a, K, V> Sync for ValuesMut<'a, K, V>where
    K: Sync,
    V: Sync,

impl<K, V> Sync for HopSlotMap<K, V>where
    V: Sync,

impl<'a, K, V> Sync for Drain<'a, K, V>where
    V: Sync,

impl<K, V> Sync for IntoIter<K, V>where
    V: Sync,

impl<'a, K, V> Sync for Iter<'a, K, V>where
    V: Sync,

impl<'a, K, V> Sync for IterMut<'a, K, V>where
    V: Sync,

impl<'a, K, V> Sync for Keys<'a, K, V>where
    V: Sync,

impl<'a, K, V> Sync for Values<'a, K, V>where
    V: Sync,

impl<'a, K, V> Sync for ValuesMut<'a, K, V>where
    V: Sync,

impl<K, V> Sync for SecondaryMap<K, V>where
    V: Sync,

impl<'a, K, V> Sync for OccupiedEntry<'a, K, V>where
    V: Sync,

impl<'a, K, V> Sync for VacantEntry<'a, K, V>where
    V: Sync,

impl<'a, K, V> Sync for Entry<'a, K, V>where
    V: Sync,

impl<'a, K, V> Sync for Drain<'a, K, V>where
    V: Sync,

impl<K, V> Sync for IntoIter<K, V>where
    V: Sync,

impl<'a, K, V> Sync for Iter<'a, K, V>where
    V: Sync,

impl<'a, K, V> Sync for IterMut<'a, K, V>where
    V: Sync,

impl<'a, K, V> Sync for Keys<'a, K, V>where
    V: Sync,

impl<'a, K, V> Sync for Values<'a, K, V>where
    V: Sync,

impl<'a, K, V> Sync for ValuesMut<'a, K, V>where
    V: Sync,

impl<K, V, S> Sync for SparseSecondaryMap<K, V, S>where
    S: Sync,
    V: Sync,

impl<'a, K, V> Sync for OccupiedEntry<'a, K, V>where
    V: Sync,

impl<'a, K, V> Sync for VacantEntry<'a, K, V>where
    V: Sync,

impl<'a, K, V> Sync for Entry<'a, K, V>where
    V: Sync,

impl<'a, K, V> Sync for Drain<'a, K, V>where
    V: Sync,

impl<K, V> Sync for IntoIter<K, V>where
    V: Sync,

impl<'a, K, V> Sync for Iter<'a, K, V>where
    V: Sync,

impl<'a, K, V> Sync for IterMut<'a, K, V>where
    V: Sync,

impl<'a, K, V> Sync for Keys<'a, K, V>where
    V: Sync,

impl<'a, K, V> Sync for Values<'a, K, V>where
    V: Sync,

impl<'a, K, V> Sync for ValuesMut<'a, K, V>where
    V: Sync,

impl Sync for KeyData

impl Sync for DefaultKey

impl<A> Sync for SmallVec<A>where
    A: Sync,

impl<A> Sync for IntoIter<A>where
    A: Sync,

impl Sync for Encoder

impl Sync for Decoder

impl<W> Sync for IntoInnerError<W>where
    W: Sync,

impl Sync for Error

impl<R> Sync for FrameDecoder<R>where
    R: Sync,

impl<R> Sync for FrameEncoder<R>where
    R: Sync,

impl<W> Sync for FrameEncoder<W>where
    W: Sync,

impl Sync for Keypair

impl<'builder> !Sync for Builder<'builder>

impl Sync for Error

impl Sync for InitStage

impl Sync for BaseChoice

impl Sync for DHChoice

impl Sync for HashChoice

impl Sync for NoiseParams

impl Sync for SockAddr

impl Sync for Socket

impl<'s> Sync for SockRef<'s>

impl Sync for Domain

impl Sync for Type

impl Sync for Protocol

impl Sync for RecvFlags

impl<'a> Sync for MaybeUninitSlice<'a>

impl Sync for OpCode

impl Sync for Header

impl Sync for Codec

impl Sync for Error

impl Sync for Mode

impl<T> Sync for Sender<T>where
    T: Send,

impl<T> Sync for Receiver<T>where
    T: Send,

impl<T> !Sync for Builder<T>

impl Sync for Error

impl Sync for CloseReason

impl<'a> Sync for Incoming<'a>

impl Sync for Data

impl<'a> Sync for ByteSlice125<'a>

impl Sync for Deflate

impl<'a> Sync for Param<'a>

impl<'a, T> !Sync for Client<'a, T>

impl<'a, T> !Sync for Server<'a, T>

impl<'a> Sync for ClientRequest<'a>

impl<'a> Sync for RequestHeaders<'a>

impl<'a> Sync for Response<'a>

impl Sync for Error

impl<T, N> Sync for Parsing<T, N>where
    N: Sync,
    T: Sync,

impl<'a> Sync for Storage<'a>

impl Sync for ApiError

impl<'a, Block, NC, Backend> !Sync for CallApiAtParams<'a, Block, NC, Backend>

impl<'a, T> Sync for ApiRef<'a, T>where
    T: Sync,

impl Sync for Public

impl Sync for Signature

impl Sync for Pair

impl Sync for Public

impl Sync for Signature

impl Sync for Pair

impl Sync for Public

impl Sync for Signature

impl Sync for Pair

impl Sync for BigUint

impl Sync for FixedI64

impl Sync for FixedU64

impl Sync for FixedI128

impl Sync for FixedU128

impl Sync for Rounding

impl Sync for Percent

impl Sync for PerU16

impl Sync for Permill

impl Sync for Perbill

impl Sync for Perquintill

impl Sync for Rational128

impl<H> Sync for InherentDataProvider<H>where
    H: Sync,

impl<Block> Sync for Info<Block>

impl Sync for BlockStatus

impl Sync for Error

impl<Block> Sync for HashAndNumber<Block>

impl<Block> Sync for TreeRoute<Block>

impl<Block> Sync for HeaderMetadataCache<Block>

impl<Block> Sync for CachedHeaderMetadata<Block>

impl Sync for Validation

impl Sync for Error

impl Sync for BlockStatus

impl Sync for BlockOrigin

impl<Block, Transaction, Proof> Sync for Proposal<Block, Transaction, Proof>where
    Proof: Sync,
    Transaction: Sync,

impl Sync for NoNetwork

impl<T> Sync for CanAuthorWithNativeVersion<T>where
    T: Sync,

impl<AuthorityId> Sync for ConsensusLog<AuthorityId>where
    AuthorityId: Sync,

impl Sync for PreDigest

impl Sync for Epoch

impl Sync for Slot

impl<Header, Id> Sync for EquivocationProof<Header, Id>where
    Header: Sync,
    Id: Sync,

impl Sync for VRFOutput

impl Sync for VRFProof

impl Sync for Dummy

impl Sync for Infallible

impl Sync for PublicError

impl Sync for AccountId32

impl Sync for SecretUri

impl Sync for KeyTypeId

impl<'a> Sync for HexDisplay<'a>

impl<F> Sync for DeferGuard<F>where
    F: Sync,

impl Sync for Public

impl Sync for Signature

impl Sync for DeriveError

impl Sync for Pair

impl Sync for Public

impl Sync for Pair

impl Sync for Signature

impl Sync for DeriveError

impl Sync for PoolState

impl Sync for StorageKind

impl Sync for HttpError

impl Sync for Timestamp

impl Sync for Duration

impl<T> Sync for LimitedExternalities<T>where
    T: Sync,

impl Sync for Public

impl Sync for Pair

impl Sync for Signature

impl<'a> Sync for WrappedRuntimeCode<'a>

impl<'a> !Sync for RuntimeCode<'a>

impl Sync for Bytes

impl<R> Sync for NativeOrEncoded<R>where
    R: Sync,

impl Sync for LogLevel

impl Sync for Void

impl Sync for MemDb

impl<H> Sync for Change<H>where
    H: Sync,

impl<H> Sync for Transaction<H>where
    H: Sync,

impl !Sync for Extensions

impl Sync for Error

impl<N> Sync for ScheduledChange<N>where
    N: Sync,

impl<N> Sync for ConsensusLog<N>where
    N: Sync,

impl<H, N> Sync for EquivocationProof<H, N>where
    H: Sync,
    N: Sync,

impl<H, N> Sync for Equivocation<H, N>where
    H: Sync,
    N: Sync,

impl<'a> Sync for VersionedAuthorityList<'a>

impl Sync for Error

impl<E> Sync for MakeFatalError<E>where
    E: Sync,

impl<T> Sync for Crossing<T>where
    T: Sync,

impl Sync for Keyring

impl Sync for KeyringIter

impl Sync for Keyring

impl Sync for KeyringIter

impl Sync for KeyStore

impl Sync for Error

impl Sync for KeystoreExt

impl Sync for Error

impl<Hash> Sync for Proof<Hash>where
    Hash: Sync,

impl Sync for OpaqueLeaf

impl<H, L> Sync for DataOrHash<H, L>where
    L: Sync,

impl<H, T> Sync for Compact<H, T>where
    H: Sync,
    T: Sync,

impl<Hash> Sync for BatchProof<Hash>where
    Hash: Sync,

impl Sync for Error

impl<AccountId, P> Sync for Assignment<AccountId, P>where
    AccountId: Sync,
    P: Sync,

impl<AccountId> Sync for StakedAssignment<AccountId>where
    AccountId: Sync,

impl Sync for Error

impl<AccountId> Sync for Candidate<AccountId>where
    AccountId: Sync,

impl<AccountId> !Sync for Edge<AccountId>

impl<AccountId> !Sync for Voter<AccountId>

impl<AccountId, P> Sync for ElectionResult<AccountId, P>where
    AccountId: Sync,
    P: Sync,

impl<AccountId> Sync for Support<AccountId>where
    AccountId: Sync,

impl !Sync for AbortGuard

impl<T> Sync for ListOrValue<T>where
    T: Sync,

impl Sync for NumberOrHex

impl Sync for BlockTrace

impl Sync for Event

impl Sync for Span

impl Sync for Data

impl Sync for TraceError

impl<K, V, S> Sync for BoundedBTreeMap<K, V, S>where
    K: Sync,
    S: Sync,
    V: Sync,

impl<T, S> Sync for BoundedBTreeSet<T, S>where
    S: Sync,
    T: Sync,

impl<T, S> Sync for BoundedVec<T, S>where
    S: Sync,
    T: Sync,

impl<'a, T, S> Sync for BoundedSlice<'a, T, S>where
    S: Sync,
    T: Sync,

impl<T, S> Sync for WeakBoundedVec<T, S>where
    S: Sync,
    T: Sync,

impl<'a> Sync for PiecewiseLinear<'a>

impl<Block> Sync for BlockId<Block>

impl<Header, Extrinsic> Sync for Block<Header, Extrinsic>where
    Extrinsic: Sync,
    Header: Sync,

impl<Block> Sync for SignedBlock<Block>where
    Block: Sync,

impl<AccountId, Call, Extra> Sync for CheckedExtrinsic<AccountId, Call, Extra>where
    AccountId: Sync,
    Call: Sync,
    Extra: Sync,

impl Sync for Digest

impl Sync for DigestItem

impl<'a> Sync for DigestItemRef<'a>

impl<'a> Sync for OpaqueDigestItemId<'a>

impl Sync for Era

impl<Number, Hash> Sync for Header<Number, Hash>where
    Number: Sync,

impl<Address, Call, Signature, Extra> Sync for UncheckedExtrinsic<Address, Call, Signature, Extra>where
    Address: Sync,
    Call: Sync,
    Signature: Sync,

impl<Call, Extra> Sync for SignedPayload<Call, Extra>where
    Call: Sync,
    <Extra as SignedExtension>::AdditionalSigned: Sync,

impl Sync for ModuleError

impl<AccountId, AccountIndex> Sync for MultiAddress<AccountId, AccountIndex>where
    AccountId: Sync,
    AccountIndex: Sync,

impl Sync for Method

impl<'a, T> Sync for Request<'a, T>where
    T: Sync,

impl Sync for Error

impl Sync for Response

impl Sync for Headers

impl<'a> Sync for HeadersIterator<'a>

impl<'a> Sync for StorageValueRef<'a>

impl<T, E> Sync for MutateStorageError<T, E>where
    E: Sync,
    T: Sync,

impl Sync for Time

impl<B> Sync for BlockAndTimeDeadline<B>where
    <B as BlockNumberProvider>::BlockNumber: Sync,

impl<B> Sync for BlockAndTime<B>where
    B: Sync,

impl<'a, L> Sync for StorageLock<'a, L>where
    L: Sync,

impl<'a, 'b, L> Sync for StorageLockGuard<'a, 'b, L>where
    L: Sync,

impl<Xt> Sync for ExtrinsicWrapper<Xt>where
    Xt: Sync,

impl<Xt> Sync for Block<Xt>where
    Xt: Sync,

impl<Call, Extra> Sync for TestXt<Call, Extra>where
    Call: Sync,
    Extra: Sync,

impl Sync for BadOrigin

impl Sync for LookupError

impl<T> Sync for IdentityLookup<T>where
    T: Sync,

impl<AccountId, AccountIndex> Sync for AccountIdLookup<AccountId, AccountIndex>where
    AccountId: Sync,
    AccountIndex: Sync,

impl Sync for GetDefault

impl<const T: bool> Sync for ConstBool<T>

impl<const T: u8> Sync for ConstU8<T>

impl<const T: u16> Sync for ConstU16<T>

impl<const T: u32> Sync for ConstU32<T>

impl<const T: u64> Sync for ConstU64<T>

impl<const T: u128> Sync for ConstU128<T>

impl<const T: i8> Sync for ConstI8<T>

impl<const T: i16> Sync for ConstI16<T>

impl<const T: i32> Sync for ConstI32<T>

impl<const T: i64> Sync for ConstI64<T>

impl<const T: i128> Sync for ConstI128<T>

impl<V> Sync for Replace<V>where
    V: Sync,

impl<N> Sync for ReduceBy<N>where
    N: Sync,

impl Sync for Identity

impl Sync for ConvertInto

impl Sync for BlakeTwo256

impl Sync for Keccak256

impl<'a, T> Sync for AppendZerosInput<'a, T>where
    T: Sync,

impl<'a> Sync for TrailingZeroInput<'a>

impl Sync for MultiSigner

impl Sync for ModuleError

impl<Info> Sync for DispatchErrorWithPostInfo<Info>where
    Info: Sync,

impl Sync for TokenError

impl<R> Sync for TransactionOutcome<R>where
    R: Sync,

impl<T> Sync for Codec<T>where
    T: Sync,

impl<T, I> Sync for Inner<T, I>where
    I: Sync,
    T: Sync,

impl<T> Sync for Enum<T>where
    T: Sync,

impl<T, O> Sync for WrappedFFIValue<T, O>where
    O: Sync,
    T: Sync,

impl<T> Sync for RestoreImplementation<T>where
    T: Sync,

impl !Sync for Memory

impl<T> !Sync for Instance<T>

impl Sync for HostError

impl Sync for Entry

impl Sync for Error

impl<Reporter, Offender> Sync for OffenceDetails<Reporter, Offender>where
    Offender: Sync,
    Reporter: Sync,

impl<'a, B, H> Sync for BackendRuntimeCode<'a, B, H>where
    B: Sync,
    H: Sync,

impl<'a, H, B> !Sync for Ext<'a, H, B>

impl<Transaction, H> Sync for StorageChanges<Transaction, H>where
    Transaction: Sync,

impl<Transaction, H> Sync for StorageTransactionCache<Transaction, H>where
    Transaction: Sync,

impl<'a, H, B> Sync for ReadOnlyExternalities<'a, H, B>where
    B: Sync,

impl Sync for UsageUnit

impl Sync for UsageInfo

impl<H> !Sync for TestExternalities<H>

impl<S, H, C> Sync for TrieBackendBuilder<S, H, C>where
    C: Sync,

impl<S, H, C> Sync for TrieBackend<S, H, C>where
    C: Sync,

impl<F> Sync for ExecutionManager<F>where
    F: Sync,

impl<'a, B, H, Exec> !Sync for StateMachine<'a, B, H, Exec>

impl Sync for Writer

impl Sync for StorageKey

impl Sync for StorageData

impl Sync for Storage

impl<Hash> Sync for StorageChangeSet<Hash>where
    Hash: Sync,

impl Sync for ChildInfo

impl Sync for ChildType

impl Sync for Timestamp

impl Sync for WasmLevel

impl Sync for WasmValue

impl Sync for WasmFields

impl<H> Sync for SharedTrieCache<H>

impl Sync for CacheSize

impl<H> Sync for LocalTrieCache<H>

impl<'a, H> Sync for TrieCache<'a, H>

impl<H> Sync for Error<H>where
    H: Sync,

impl<H> Sync for NodeCodec<H>where
    H: Sync,

impl<H> Sync for Recorder<H>

impl<H, CodecError> Sync for Error<H, CodecError>where
    CodecError: Sync,
    H: Sync,

impl Sync for TrieStream

impl<H> Sync for LayoutV0<H>where
    H: Sync,

impl<H> Sync for LayoutV1<H>where
    H: Sync,

impl<'a, DB: ?Sized, H> Sync for KeySpacedDB<'a, DB, H>where
    DB: Sync,
    H: Sync,

impl<'a, DB: ?Sized, H> Sync for KeySpacedDBMut<'a, DB, H>where
    DB: Sync,
    H: Sync,

impl Sync for Error

impl Sync for ValueType

impl Sync for Value

impl<T> Sync for Pointer<T>where
    T: Sync,

impl Sync for Signature

impl<Base, Overlay> Sync for ExtendedHostFunctions<Base, Overlay>where
    Base: Sync,
    Overlay: Sync,

impl Sync for ReturnValue

impl<'a, T: ?Sized> Sync for MutexGuard<'a, T>where
    T: Sync,

impl<'a, T> !Sync for RwLockReadGuard<'a, T>

impl<'a, T> !Sync for RwLockWriteGuard<'a, T>

impl<'a, T> !Sync for RwLockUpgradeableGuard<'a, T>

impl Sync for ParseError

impl Sync for Token

impl Sync for TokenAmount

impl<T, F> Sync for ConstLazy<T, F>where
    T: Sync,

impl<T, F = fn() -> T> !Sync for Lazy<T, F>

impl<T, F = fn() -> T> !Sync for ConstLazy<T, F>

impl<T> Sync for Static<T>where
    T: Sync,

impl Sync for Bernoulli

impl Sync for Beta

impl Sync for Binomial

impl Sync for Categorical

impl Sync for Cauchy

impl Sync for Chi

impl Sync for ChiSquared

impl Sync for Dirac

impl Sync for Dirichlet

impl Sync for Empirical

impl Sync for Erlang

impl Sync for Exp

impl Sync for Gamma

impl Sync for Geometric

impl Sync for Laplace

impl Sync for LogNormal

impl Sync for Multinomial

impl Sync for Normal

impl Sync for Pareto

impl Sync for Poisson

impl Sync for StudentsT

impl Sync for Triangular

impl Sync for Uniform

impl Sync for Weibull

impl<D> Sync for Data<D>where
    D: Sync,

impl Sync for StatsError

impl Sync for StrSimError

impl Sync for ParseError

impl Sync for Error

impl Sync for Error

impl<P, C, B> Sync for System<P, C, B>where
    B: Sync,
    C: Send + Sync,

impl<T, S> Sync for SourcedMetric<T, S>where
    S: Sync,
    T: Sync,

impl Sync for Error

impl<C, B, BA> Sync for StateMigration<C, B, BA>where
    B: Sync,
    BA: Send + Sync,
    C: Send + Sync,

impl Sync for Choice

impl<T> Sync for CtOption<T>where
    T: Sync,

impl !Sync for Underscore

impl !Sync for Abstract

impl !Sync for As

impl !Sync for Async

impl !Sync for Auto

impl !Sync for Await

impl !Sync for Become

impl !Sync for Box

impl !Sync for Break

impl !Sync for Const

impl !Sync for Continue

impl !Sync for Crate

impl !Sync for Default

impl !Sync for Do

impl !Sync for Dyn

impl !Sync for Else

impl !Sync for Enum

impl !Sync for Extern

impl !Sync for Final

impl !Sync for Fn

impl !Sync for For

impl !Sync for If

impl !Sync for Impl

impl !Sync for In

impl !Sync for Let

impl !Sync for Loop

impl !Sync for Macro

impl !Sync for Match

impl !Sync for Mod

impl !Sync for Move

impl !Sync for Mut

impl !Sync for Override

impl !Sync for Priv

impl !Sync for Pub

impl !Sync for Ref

impl !Sync for Return

impl !Sync for SelfType

impl !Sync for SelfValue

impl !Sync for Static

impl !Sync for Struct

impl !Sync for Super

impl !Sync for Trait

impl !Sync for Try

impl !Sync for Type

impl !Sync for Typeof

impl !Sync for Union

impl !Sync for Unsafe

impl !Sync for Unsized

impl !Sync for Use

impl !Sync for Virtual

impl !Sync for Where

impl !Sync for While

impl !Sync for Yield

impl !Sync for Add

impl !Sync for AddEq

impl !Sync for And

impl !Sync for AndAnd

impl !Sync for AndEq

impl !Sync for At

impl !Sync for Bang

impl !Sync for Caret

impl !Sync for CaretEq

impl !Sync for Colon

impl !Sync for Colon2

impl !Sync for Comma

impl !Sync for Div

impl !Sync for DivEq

impl !Sync for Dollar

impl !Sync for Dot

impl !Sync for Dot2

impl !Sync for Dot3

impl !Sync for DotDotEq

impl !Sync for Eq

impl !Sync for EqEq

impl !Sync for Ge

impl !Sync for Gt

impl !Sync for Le

impl !Sync for Lt

impl !Sync for MulEq

impl !Sync for Ne

impl !Sync for Or

impl !Sync for OrEq

impl !Sync for OrOr

impl !Sync for Pound

impl !Sync for Question

impl !Sync for RArrow

impl !Sync for LArrow

impl !Sync for Rem

impl !Sync for RemEq

impl !Sync for FatArrow

impl !Sync for Semi

impl !Sync for Shl

impl !Sync for ShlEq

impl !Sync for Shr

impl !Sync for ShrEq

impl !Sync for Star

impl !Sync for Sub

impl !Sync for SubEq

impl !Sync for Tilde

impl !Sync for Brace

impl !Sync for Bracket

impl !Sync for Paren

impl !Sync for Group

impl !Sync for Attribute

impl !Sync for AttrStyle

impl !Sync for Meta

impl !Sync for MetaList

impl !Sync for NestedMeta

impl !Sync for Variant

impl !Sync for Fields

impl !Sync for FieldsNamed

impl !Sync for Field

impl !Sync for Visibility

impl !Sync for VisPublic

impl !Sync for VisCrate

impl !Sync for Expr

impl !Sync for ExprArray

impl !Sync for ExprAssign

impl !Sync for ExprAssignOp

impl !Sync for ExprAsync

impl !Sync for ExprAwait

impl !Sync for ExprBinary

impl !Sync for ExprBlock

impl !Sync for ExprBox

impl !Sync for ExprBreak

impl !Sync for ExprCall

impl !Sync for ExprCast

impl !Sync for ExprClosure

impl !Sync for ExprContinue

impl !Sync for ExprField

impl !Sync for ExprForLoop

impl !Sync for ExprGroup

impl !Sync for ExprIf

impl !Sync for ExprIndex

impl !Sync for ExprLet

impl !Sync for ExprLit

impl !Sync for ExprLoop

impl !Sync for ExprMacro

impl !Sync for ExprMatch

impl !Sync for ExprParen

impl !Sync for ExprPath

impl !Sync for ExprRange

impl !Sync for ExprRepeat

impl !Sync for ExprReturn

impl !Sync for ExprStruct

impl !Sync for ExprTry

impl !Sync for ExprTryBlock

impl !Sync for ExprTuple

impl !Sync for ExprType

impl !Sync for ExprUnary

impl !Sync for ExprUnsafe

impl !Sync for ExprWhile

impl !Sync for ExprYield

impl !Sync for Member

impl !Sync for Index

impl !Sync for FieldValue

impl !Sync for Label

impl !Sync for Arm

impl !Sync for RangeLimits

impl !Sync for Generics

impl !Sync for GenericParam

impl !Sync for TypeParam

impl !Sync for LifetimeDef

impl !Sync for ConstParam

impl<'a> !Sync for ImplGenerics<'a>

impl<'a> !Sync for TypeGenerics<'a>

impl<'a> !Sync for Turbofish<'a>

impl !Sync for TraitBound

impl !Sync for WhereClause

impl !Sync for PredicateEq

impl !Sync for Item

impl !Sync for ItemConst

impl !Sync for ItemEnum

impl !Sync for ItemFn

impl !Sync for ItemImpl

impl !Sync for ItemMacro

impl !Sync for ItemMacro2

impl !Sync for ItemMod

impl !Sync for ItemStatic

impl !Sync for ItemStruct

impl !Sync for ItemTrait

impl !Sync for ItemType

impl !Sync for ItemUnion

impl !Sync for ItemUse

impl !Sync for UseTree

impl !Sync for UsePath

impl !Sync for UseName

impl !Sync for UseRename

impl !Sync for UseGlob

impl !Sync for UseGroup

impl !Sync for ForeignItem

impl !Sync for TraitItem

impl !Sync for ImplItem

impl !Sync for ImplItemType

impl !Sync for Signature

impl !Sync for FnArg

impl !Sync for Receiver

impl !Sync for File

impl !Sync for Lifetime

impl !Sync for Lit

impl !Sync for LitStr

impl !Sync for LitByteStr

impl !Sync for LitByte

impl !Sync for LitChar

impl !Sync for LitInt

impl !Sync for LitFloat

impl !Sync for LitBool

impl Sync for StrStyle

impl !Sync for Macro

impl !Sync for DeriveInput

impl !Sync for Data

impl !Sync for DataStruct

impl !Sync for DataEnum

impl !Sync for DataUnion

impl !Sync for BinOp

impl !Sync for UnOp

impl !Sync for Block

impl !Sync for Stmt

impl !Sync for Local

impl !Sync for Type

impl !Sync for TypeArray

impl !Sync for TypeBareFn

impl !Sync for TypeGroup

impl !Sync for TypeInfer

impl !Sync for TypeMacro

impl !Sync for TypeNever

impl !Sync for TypeParen

impl !Sync for TypePath

impl !Sync for TypePtr

impl !Sync for TypeSlice

impl !Sync for TypeTuple

impl !Sync for Abi

impl !Sync for BareFnArg

impl !Sync for Variadic

impl !Sync for ReturnType

impl !Sync for Pat

impl !Sync for PatBox

impl !Sync for PatIdent

impl !Sync for PatLit

impl !Sync for PatMacro

impl !Sync for PatOr

impl !Sync for PatPath

impl !Sync for PatRange

impl !Sync for PatReference

impl !Sync for PatRest

impl !Sync for PatSlice

impl !Sync for PatStruct

impl !Sync for PatTuple

impl !Sync for PatType

impl !Sync for PatWild

impl !Sync for FieldPat

impl !Sync for Path

impl !Sync for PathSegment

impl !Sync for Binding

impl !Sync for Constraint

impl !Sync for QSelf

impl !Sync for TokenBuffer

impl<'a> !Sync for Cursor<'a>

impl<T, P> Sync for Punctuated<T, P>where
    P: Sync,
    T: Sync,

impl<'a, T, P> Sync for Pairs<'a, T, P>where
    P: Sync,
    T: Sync,

impl<'a, T, P> Sync for PairsMut<'a, T, P>where
    P: Sync,
    T: Sync,

impl<T, P> Sync for IntoPairs<T, P>where
    P: Sync,
    T: Sync,

impl<T> Sync for IntoIter<T>where
    T: Sync,

impl<'a, T> !Sync for Iter<'a, T>

impl<'a, T> !Sync for IterMut<'a, T>

impl<T, P> Sync for Pair<T, P>where
    P: Sync,
    T: Sync,

impl<'a> !Sync for Lookahead1<'a>

impl Sync for Error

impl<'a> !Sync for ParseBuffer<'a>

impl<'c, 'a> !Sync for StepCursor<'c, 'a>

impl Sync for Nothing

impl Sync for AddBounds

impl Sync for BindStyle

impl<'a> !Sync for BindingInfo<'a>

impl<'a> !Sync for VariantAst<'a>

impl<'a> !Sync for VariantInfo<'a>

impl<'a> !Sync for Structure<'a>

impl Sync for Size

impl Sync for CDataModel

impl Sync for ParseError

impl Sync for Vendor

impl Sync for Environment

impl Sync for Endianness

impl Sync for Triple

impl Sync for TempDir

impl Sync for TempPath

impl<'a, 'b> Sync for Builder<'a, 'b>

impl Sync for ColorChoice

impl<'a> Sync for StandardStreamLock<'a>

impl Sync for Buffer

impl<W> Sync for NoColor<W>where
    W: Sync,

impl<W> Sync for Ansi<W>where
    W: Sync,

impl Sync for ColorSpec

impl Sync for Color

impl Sync for Ancestry

impl Sync for XcmConfig

impl Sync for Alternative

impl Sync for SessionKeys

impl Sync for BaseFilter

impl Sync for Period

impl Sync for WeightToFee

impl<T> Sync for AssetPairAccountId<T>where
    T: Sync,

impl Sync for Version

impl Sync for ItemDeposit

impl Sync for KeyLimit

impl Sync for ValueLimit

impl Sync for Runtime

impl Sync for Event

impl !Sync for Origin

impl Sync for PalletInfo

impl Sync for Call

impl Sync for RuntimeApi

impl Sync for LineEnding

impl<'a> Sync for Word<'a>

impl<'a> Sync for Options<'a>

impl<'a> Sync for SeparatorPolicy<'a>

impl<T> Sync for CachedThreadLocal<T>

impl<'a, T> Sync for CachedIterMut<'a, T>

impl<T> Sync for CachedIntoIter<T>

impl<'a, T> Sync for Iter<'a, T>

impl<'a, T> Sync for IterMut<'a, T>

impl<T> Sync for IntoIter<T>

impl Sync for Builder

impl !Sync for ThreadPool

impl<T> Sync for TBinaryInputProtocol<T>where
    T: Sync,

impl<T> Sync for TBinaryOutputProtocol<T>where
    T: Sync,

impl<T> Sync for TCompactInputProtocol<T>where
    T: Sync,

impl<T> Sync for TCompactOutputProtocol<T>where
    T: Sync,

impl<P> Sync for TMultiplexedOutputProtocol<P>where
    P: Sync,

impl<'a> !Sync for TStoredInputProtocol<'a>

impl Sync for TType

impl<PRC, RTF, IPF, WTF, OPF> !Sync for TServer<PRC, RTF, IPF, WTF, OPF>

impl<C> Sync for TBufferedReadTransport<C>where
    C: Sync,

impl<C> Sync for TBufferedWriteTransport<C>where
    C: Sync,

impl<C> Sync for TFramedReadTransport<C>where
    C: Sync,

impl<C> Sync for TFramedWriteTransport<C>where
    C: Sync,

impl Sync for TTcpChannel

impl<C> Sync for ReadHalf<C>where
    C: Sync,

impl<C> Sync for WriteHalf<C>where
    C: Sync,

impl Sync for Error

impl Sync for Duration

impl Sync for Timespec

impl Sync for PreciseTime

impl Sync for SteadyTime

impl Sync for Tm

impl Sync for ParseError

impl<'a> Sync for TmFmt<'a>

impl<A> Sync for ArrayVec<A>where
    A: Sync,

impl<'p, A, I> Sync for ArrayVecSplice<'p, A, I>where
    A: Sync,
    I: Sync,

impl<A> Sync for ArrayVecIterator<A>where
    A: Sync,

impl<'a, T> Sync for ArrayVecDrain<'a, T>where
    T: Sync,

impl<'s, T> Sync for SliceVec<'s, T>where
    T: Sync,

impl<'p, 's, T> Sync for SliceVecDrain<'p, 's, T>where
    T: Sync,

impl<A> Sync for TinyVec<A>where
    A: Sync,
    <A as Array>::Item: Sync,

impl<'p, A> Sync for TinyVecDrain<'p, A>where
    <A as Array>::Item: Sync,

impl<'p, A, I> Sync for TinyVecSplice<'p, A, I>where
    A: Sync,
    I: Sync,
    <A as Array>::Item: Sync,

impl<A> Sync for TinyVecIterator<A>where
    A: Sync,
    <A as Array>::Item: Sync,

impl<'a> Sync for ReadBuf<'a>

impl Sync for Interest

impl Sync for Ready

impl<T> Sync for AsyncFd<T>where
    T: Sync,

impl<'a, T> Sync for AsyncFdReadyGuard<'a, T>where
    T: Sync,

impl<'a, T> Sync for AsyncFdReadyMutGuard<'a, T>where
    T: Sync,

impl Sync for TryIoError

impl<R> Sync for BufReader<R>where
    R: Sync,

impl<RW> Sync for BufStream<RW>where
    RW: Sync,

impl<W> Sync for BufWriter<W>where
    W: Sync,

impl Sync for Empty

impl<R> Sync for Lines<R>where
    R: Sync,

impl Sync for Repeat

impl Sync for Sink

impl<R> Sync for Split<R>where
    R: Sync,

impl<R> Sync for Take<R>where
    R: Sync,

impl Sync for TcpListener

impl Sync for TcpSocket

impl<'a> Sync for ReadHalf<'a>

impl<'a> Sync for WriteHalf<'a>

impl Sync for TcpStream

impl Sync for UdpSocket

impl<'a> Sync for ReadHalf<'a>

impl<'a> Sync for WriteHalf<'a>

impl Sync for SocketAddr

impl Sync for UnixStream

impl Sync for UCred

impl Sync for JoinError

impl Sync for Builder

impl Sync for Handle

impl<'a> Sync for EnterGuard<'a>

impl Sync for Runtime

impl Sync for SignalKind

impl Sync for Signal

impl Sync for Barrier

impl<T> Sync for SendError<T>where
    T: Sync,

impl Sync for RecvError

impl<T> Sync for Sender<T>where
    T: Send,

impl<T> Sync for WeakSender<T>where
    T: Send,

impl<'a, T> Sync for Permit<'a, T>where
    T: Send,

impl<T> Sync for OwnedPermit<T>where
    T: Send,

impl<T> Sync for Receiver<T>where
    T: Send,

impl<T> Sync for UnboundedSender<T>where
    T: Send,

impl<T> Sync for UnboundedReceiver<T>where
    T: Send,

impl<T> Sync for SendError<T>where
    T: Sync,

impl<T> Sync for TrySendError<T>where
    T: Sync,

impl<T> Sync for SendTimeoutError<T>where
    T: Sync,

impl Sync for Notify

impl Sync for RecvError

impl<T> Sync for Sender<T>where
    T: Send,

impl<T> Sync for Receiver<T>where
    T: Send,

impl Sync for Semaphore

impl<'a> Sync for SemaphorePermit<'a>

impl<T> Sync for SetError<T>where
    T: Sync,

impl<T> Sync for SendError<T>where
    T: Sync,

impl Sync for RecvError

impl<T> Sync for Receiver<T>where
    T: Send + Sync,

impl<T> Sync for Sender<T>where
    T: Send + Sync,

impl<'a, T> Sync for Ref<'a, T>where
    T: Send + Sync,

impl !Sync for LocalSet

impl<T> Sync for LocalKey<T>

impl<T, F> Sync for TaskLocalFuture<T, F>where
    F: Sync,
    T: Sync,

impl<F> Sync for Unconstrained<F>where
    F: Sync,

impl<T> Sync for JoinSet<T>where
    T: Send,

impl Sync for Sleep

impl Sync for Error

impl Sync for Elapsed

impl Sync for Instant

impl Sync for Interval

impl<T> Sync for Timeout<T>where
    T: Sync,

impl<IO> Sync for TlsStream<IO>where
    IO: Sync,

impl<IO> Sync for TlsStream<IO>where
    IO: Sync,

impl Sync for TlsAcceptor

impl<IO> Sync for LazyConfigAcceptor<IO>where
    IO: Sync,

impl<IO> Sync for StartHandshake<IO>where
    IO: Sync,

impl<IO> Sync for Connect<IO>where
    IO: Sync,

impl<IO> Sync for Accept<IO>where
    IO: Sync,

impl<IO> Sync for FallibleConnect<IO>where
    IO: Sync,

impl<IO> Sync for FallibleAccept<IO>where
    IO: Sync,

impl<T> Sync for TlsStream<T>where
    T: Sync,

impl<T> Sync for ReceiverStream<T>where
    T: Send,

impl<T> Sync for UnboundedReceiverStream<T>where
    T: Send,

impl<S> Sync for Timeout<S>where
    S: Sync,

impl Sync for Elapsed

impl<I> Sync for Iter<I>where
    I: Sync,

impl<T> Sync for Once<T>where
    T: Sync,

impl<K, V> Sync for StreamMap<K, V>where
    K: Sync,
    V: Sync,

impl Sync for BytesCodec

impl<T, U> Sync for Framed<T, U>where
    T: Sync,
    U: Sync,

impl<T, U> Sync for FramedParts<T, U>where
    T: Sync,
    U: Sync,

impl<T, D> Sync for FramedRead<T, D>where
    D: Sync,
    T: Sync,

impl<T, E> Sync for FramedWrite<T, E>where
    E: Sync,
    T: Sync,

impl Sync for Builder

impl Sync for LinesCodec

impl<T> Sync for Compat<T>where
    T: Sync,

impl Sync for DropGuard

impl<T> Sync for PollSendError<T>where
    T: Sync,

impl<T> Sync for PollSender<T>where
    T: Send,

impl<L, R> Sync for Either<L, R>where
    L: Sync,
    R: Sync,

impl<K, V> Sync for Map<K, V>where
    K: Sync,
    V: Sync,

impl<'a> Sync for Entry<'a>

impl<'a> Sync for VacantEntry<'a>

impl<'a> Sync for OccupiedEntry<'a>

impl<'a> Sync for Iter<'a>

impl<'a> Sync for IterMut<'a>

impl Sync for IntoIter

impl<'a> Sync for Keys<'a>

impl<'a> Sync for Values<'a>

impl Sync for Date

impl Sync for Datetime

impl Sync for Offset

impl Sync for Time

impl Sync for Value

impl Sync for Error

impl<'a> !Sync for Serializer<'a>

impl Sync for Error

impl<'a> Sync for Deserializer<'a>

impl<T> Sync for Spanned<T>where
    T: Sync,

impl<T> Sync for WithDispatch<T>where
    T: Sync,

impl<T> Sync for Instrumented<T>where
    T: Sync,

impl Sync for Span

impl<'a> Sync for Entered<'a>

impl Sync for EnteredSpan

impl Sync for Identifier

impl Sync for Dispatch

impl<'a> !Sync for Event<'a>

impl Sync for Field

impl Sync for Empty

impl Sync for FieldSet

impl<'a> !Sync for ValueSet<'a>

impl Sync for Iter

impl<T> Sync for DisplayValue<T>where
    T: Sync,

impl<T> Sync for DebugValue<T>where
    T: Sync,

impl<'a> Sync for Metadata<'a>

impl Sync for Kind

impl Sync for Level

impl Sync for LevelFilter

impl Sync for Id

impl<'a> !Sync for Attributes<'a>

impl<'a> !Sync for Record<'a>

impl Sync for Current

impl Sync for Interest

impl<T> Sync for Instrumented<T>where
    T: Sync,

impl<T> Sync for WithDispatch<T>where
    T: Sync,

impl Sync for LogTracer

impl Sync for Builder

impl Sync for TraceLogger

impl Sync for Builder

impl<'a, T> Sync for SerializeFieldMap<'a, T>where
    T: Sync,

impl<'a> Sync for SerializeFieldSet<'a>

impl<'a> Sync for SerializeLevel<'a>

impl<'a> Sync for SerializeId<'a>

impl<'a> Sync for SerializeMetadata<'a>

impl<'a> !Sync for SerializeEvent<'a>

impl<'a> !Sync for SerializeAttributes<'a>

impl<'a> !Sync for SerializeRecord<'a>

impl<S> Sync for SerdeMapVisitor<S>where
    S: Sync,
    <S as SerializeMap>::Error: Sync,

impl<S> Sync for SerdeStructVisitor<S>where
    S: Sync,
    <S as SerializeStruct>::Error: Sync,

impl<V> Sync for Alt<V>where
    V: Sync,

impl<D, V> Sync for Delimited<D, V>where
    D: Sync,
    V: Sync,

impl<D, V> Sync for VisitDelimited<D, V>where
    D: Sync,
    V: Sync,

impl<V> Sync for Messages<V>where
    V: Sync,

impl Sync for ParseError

impl Sync for Directive

impl Sync for BadName

impl Sync for EnvFilter

impl<F> Sync for FilterFn<F>where
    F: Sync,

impl<S, F, R> Sync for DynFilterFn<S, F, R>where
    F: Sync,
    R: Sync,

impl<L, F, S> Sync for Filtered<L, F, S>where
    F: Sync,
    L: Sync,

impl Sync for FilterId

impl Sync for Targets

impl Sync for IntoIter

impl<'a> Sync for Iter<'a>

impl<S, N, E, W> Sync for Layer<S, N, E, W>where
    E: Sync,
    N: Sync,
    S: Sync,
    W: Sync,

impl<E> Sync for FormattedFields<E>

impl<'a, S, N> Sync for FmtContext<'a, S, N>where
    N: Sync,
    S: Sync,

impl Sync for Json

impl Sync for JsonFields

impl<'a> !Sync for JsonVisitor<'a>

impl Sync for Pretty

impl<'a> !Sync for PrettyVisitor<'a>

impl<F> Sync for FieldFn<F>where
    F: Sync,

impl<'a, F> !Sync for FieldFnVisitor<'a, F>

impl Sync for Compact

impl Sync for Full

impl<F, T> Sync for Format<F, T>where
    F: Sync,
    T: Sync,

impl<'a> !Sync for DefaultVisitor<'a>

impl Sync for FmtSpan

impl Sync for SystemTime

impl Sync for Uptime

impl Sync for ChronoUtc

impl Sync for ChronoLocal

impl Sync for TestWriter

impl<A, B> Sync for EitherWriter<A, B>where
    A: Sync,
    B: Sync,

impl<M> Sync for WithMaxLevel<M>where
    M: Sync,

impl<M> Sync for WithMinLevel<M>where
    M: Sync,

impl<M, F> Sync for WithFilter<M, F>where
    F: Sync,
    M: Sync,

impl<A, B> Sync for OrElse<A, B>where
    A: Sync,
    B: Sync,

impl<A, B> Sync for Tee<A, B>where
    A: Sync,
    B: Sync,

impl<W> Sync for ArcWriter<W>where
    W: Send + Sync,

impl<N, E, F, W> Sync for Subscriber<N, E, F, W>where
    E: Sync,
    F: Sync,
    N: Sync,
    W: Sync,

impl<N, E, F, W> Sync for SubscriberBuilder<N, E, F, W>where
    E: Sync,
    F: Sync,
    N: Sync,
    W: Sync,

impl<'a, S> Sync for Context<'a, S>where
    S: Sync,

impl<'a, L> Sync for Scope<'a, L>where
    L: Sync,
    <L as LookupSpan<'a>>::Data: Sync,

impl<L, I, S> Sync for Layered<L, I, S>where
    I: Sync,
    L: Sync,

impl Sync for Identity

impl<'a> Sync for Extensions<'a>

impl<'a> Sync for ExtensionsMut<'a>

impl Sync for Registry

impl<'a> !Sync for Data<'a>

impl<'a, R> Sync for SpanRef<'a, R>where
    R: Sync,
    <R as LookupSpan<'a>>::Data: Sync,

impl<'a, R> Sync for Scope<'a, R>where
    R: Sync,

impl<'a, R> Sync for ScopeFromRoot<'a, R>where
    R: Sync,
    <R as LookupSpan<'a>>::Data: Sync,

impl<'a, R> Sync for Parents<'a, R>where
    R: Sync,

impl<'a, R> Sync for FromRoot<'a, R>where
    R: Sync,
    <R as LookupSpan<'a>>::Data: Sync,

impl<L, S> Sync for Layer<L, S>where
    L: Send + Sync,

impl<L, S> Sync for Handle<L, S>where
    L: Send + Sync,

impl Sync for Error

impl Sync for CurrentSpan

impl<'a> Sync for NodeHandle<'a>

impl<H> Sync for NodeHandleOwned<H>where
    H: Sync,

impl<'a> Sync for Value<'a>

impl<H> Sync for ValueOwned<H>where
    H: Sync,

impl<'a> Sync for Node<'a>

impl<H> Sync for NodeOwned<H>where
    H: Sync,

impl Sync for ValuePlan

impl Sync for NodePlan

impl<D> Sync for OwnedNode<D>where
    D: Sync,

impl<HO, CE> Sync for Error<HO, CE>where
    CE: Sync,
    HO: Sync,

impl<HO> Sync for Record<HO>where
    HO: Sync,

impl<L> Sync for Recorder<L>

impl<'db, 'cache, L> !Sync for SecTrieDB<'db, 'cache, L>

impl<'db, L> !Sync for SecTrieDBMut<'db, L>

impl<'db, 'cache, L> !Sync for TrieDBBuilder<'db, 'cache, L>

impl<'db, 'cache, L> !Sync for TrieDB<'db, 'cache, L>

impl<'a, 'cache, L> !Sync for TrieDBIterator<'a, 'cache, L>

impl<'a, 'cache, L> !Sync for TrieDBKeyIterator<'a, 'cache, L>

impl<L> Sync for Value<L>

impl<HO> Sync for ChildReference<HO>where
    HO: Sync,

impl<'db, L> !Sync for TrieDBMutBuilder<'db, L>

impl<'a, L> !Sync for TrieDBMut<'a, L>

impl<'db, 'cache, L> !Sync for FatDB<'db, 'cache, L>

impl<'db, 'cache, L> !Sync for FatDBIterator<'db, 'cache, L>

impl<'db, L> !Sync for FatDBMut<'db, L>

impl<'a, T, DB> Sync for TrieBuilder<'a, T, DB>where
    DB: Sync,

impl<T> Sync for TrieRoot<T>

impl<T> Sync for TrieRootUnhashed<T>where
    T: Sync,

impl<T> Sync for TrieRootPrint<T>where
    T: Sync,

impl<'a, 'cache, L> !Sync for TrieDBNodeIterator<'a, 'cache, L>

impl<'a, 'cache, L, Q> !Sync for Lookup<'a, 'cache, L, Q>

impl Sync for NibbleVec

impl<'a> Sync for NibbleSlice<'a>

impl<T, E> Sync for TrieError<T, E>where
    E: Sync,
    T: Sync,

impl<'a, H> Sync for TrieAccess<'a, H>where
    H: Sync,

impl Sync for TrieSpec

impl Sync for TrieFactory

impl<'db, 'cache, L> !Sync for TrieKinds<'db, 'cache, L>

impl<H> Sync for CachedValue<H>where
    H: Sync,

impl Sync for Bytes

impl Sync for BytesWeak

impl<'a> Sync for Value<'a>

impl Sync for Unspecified

impl Sync for ProtoError

impl Sync for Edns

impl Sync for Header

impl Sync for MessageType

impl Sync for Flags

impl Sync for Message

impl Sync for OpCode

impl Sync for Query

impl Sync for QueryParts

impl Sync for DNSClass

impl Sync for Label

impl Sync for Name

impl<'a> Sync for LabelIter<'a>

impl Sync for DEFAULT

impl Sync for IP6_ARPA

impl Sync for LOCALHOST

impl Sync for IP6_ARPA_1

impl Sync for LOCAL

impl Sync for INVALID

impl Sync for ONION

impl Sync for UserUsage

impl Sync for AppUsage

impl Sync for CacheUsage

impl Sync for AuthUsage

impl Sync for OpUsage

impl Sync for ZoneUsage

impl Sync for CAA

impl Sync for Property

impl Sync for Value

impl Sync for KeyValue

impl Sync for CSYNC

impl Sync for HINFO

impl Sync for MX

impl Sync for NAPTR

impl Sync for NULL

impl Sync for OPENPGPKEY

impl Sync for OPT

impl Sync for EdnsCode

impl Sync for EdnsOption

impl Sync for SOA

impl Sync for SRV

impl Sync for HEX

impl Sync for SSHFP

impl Sync for Algorithm

impl Sync for SVCB

impl Sync for SvcParamKey

impl Sync for Mandatory

impl Sync for Alpn

impl Sync for EchConfig

impl<T> Sync for IpHint<T>where
    T: Sync,

impl Sync for Unknown

impl Sync for TLSA

impl Sync for CertUsage

impl Sync for Selector

impl Sync for Matching

impl Sync for TXT

impl Sync for RData

impl Sync for RecordType

impl Sync for Record

impl Sync for RecordParts

impl Sync for RecordSet

impl<'r> Sync for RrsetRecords<'r>

impl<'a> Sync for BinDecoder<'a>

impl Sync for DecodeError

impl<'a> Sync for BinEncoder<'a>

impl Sync for EncodeMode

impl<T> Sync for Restrict<T>where
    T: Sync,

impl<'a, T> Sync for Verified<'a, T>where
    T: Sync,

impl<S> Sync for TcpClientStream<S>

impl<S> !Sync for TcpClientConnect<S>

impl<S> Sync for TcpStream<S>

impl<S, MF> Sync for UdpClientStream<S, MF>where
    S: Sync,

impl<S, MF> Sync for UdpClientConnect<S, MF>where
    S: Sync,

impl<S> Sync for UdpStream<S>where
    S: Sync,

impl Sync for DnsExchange

impl<S, TE> Sync for DnsExchangeBackground<S, TE>where
    S: Sync,
    TE: Sync,

impl<F, S, TE> Sync for DnsExchangeConnect<F, S, TE>where
    F: Sync,
    S: Sync,
    TE: Sync,

impl<S, MF> !Sync for DnsMultiplexer<S, MF>

impl<F, S, MF> Sync for DnsMultiplexerConnect<F, S, MF>where
    F: Sync,

impl Sync for DnsRequest

impl Sync for DnsResponse

impl<H> Sync for RetryDnsHandle<H>

impl<S> Sync for FirstAnswerFuture<S>where
    S: Sync,

impl<C, P> Sync for AsyncResolver<C, P>

impl Sync for Protocol

impl Sync for Hosts

impl Sync for Lookup

impl<'a> Sync for LookupIter<'a>

impl<'a> Sync for LookupRecordIter<'a>

impl Sync for SrvLookup

impl<'i> Sync for SrvLookupIter<'i>

impl<'i> Sync for ReverseLookupIter<'i>

impl Sync for Ipv4Lookup

impl<'i> Sync for Ipv4LookupIter<'i>

impl Sync for Ipv6Lookup

impl<'i> Sync for Ipv6LookupIter<'i>

impl Sync for MxLookup

impl<'i> Sync for MxLookupIter<'i>

impl Sync for TlsaLookup

impl<'i> Sync for TlsaLookupIter<'i>

impl Sync for TxtLookup

impl<'i> Sync for TxtLookupIter<'i>

impl Sync for SoaLookup

impl<'i> Sync for SoaLookupIter<'i>

impl Sync for NsLookup

impl<'i> Sync for NsLookupIter<'i>

impl Sync for LookupIp

impl<'i> Sync for LookupIpIter<'i>

impl<C, E> !Sync for LookupIpFuture<C, E>

impl<'a, T> Sync for Locked<'a, T>where
    T: Send,

impl Sync for Command

impl Sync for State

impl Sync for XxHash64

impl Sync for XxHash32

impl Sync for Hash64

impl Sync for Hash128

impl Sync for B0

impl Sync for B1

impl<U> Sync for PInt<U>where
    U: Sync,

impl<U> Sync for NInt<U>where
    U: Sync,

impl Sync for Z0

impl Sync for UTerm

impl<U, B> Sync for UInt<U, B>where
    B: Sync,
    U: Sync,

impl Sync for ATerm

impl<V, A> Sync for TArr<V, A>where
    A: Sync,
    V: Sync,

impl Sync for Greater

impl Sync for Less

impl Sync for Equal

impl Sync for Error

impl<'a> Sync for TrieSetSlice<'a>

impl<S> Sync for UniCase<S>where
    S: Sync,

impl<S> Sync for Ascii<S>where
    S: Sync,

impl Sync for Level

impl Sync for Error

impl Sync for BidiClass

impl Sync for Direction

impl<'text> Sync for InitialInfo<'text>

impl<'text> Sync for BidiInfo<'text>

impl<'a, 'text> Sync for Paragraph<'a, 'text>

impl<I> Sync for Decompositions<I>where
    I: Sync,

impl<I> Sync for Recompositions<I>where
    I: Sync,

impl<I> Sync for Replacements<I>where
    I: Sync,

impl<I> Sync for StreamSafe<I>where
    I: Sync,

impl<U> Sync for Output<U>

impl Sync for Error

impl Sync for Error

impl Sync for ReadError

impl<T> Sync for Uvi<T>where
    T: Sync,

impl<T> Sync for UviBytes<T>where
    T: Sync,

impl<'a> Sync for Input<'a>

impl<'a> Sync for Reader<'a>

impl Sync for Mark

impl Sync for EndOfInput

impl<S> Sync for Host<S>where
    S: Sync,

impl Sync for Origin

impl Sync for ParseError

impl<'a> Sync for PathSegmentsMut<'a>

impl Sync for Position

impl Sync for Url

impl<'a> !Sync for ParseOptions<'a>

impl<'a> Sync for UrlQuery<'a>

impl Sync for Error

impl<'s, 'f> !Sync for Slot<'s, 'f>

impl<'v> !Sync for ValueBag<'v>

impl Sync for Void

impl Sync for Giver

impl Sync for Taker

impl Sync for SharedGiver

impl Sync for Closed

impl<T> Sync for WasmOption<T>where
    T: Sync,

impl<T> Sync for ResultAbi<T>where
    T: Sync,

impl<T> Sync for ResultAbiUnion<T>where
    T: Sync,

impl Sync for WasmSlice

impl<T> !Sync for Closure<T>

impl !Sync for JsValue

impl<T> Sync for JsStatic<T>

impl<T> Sync for Clamped<T>where
    T: Sync,

impl !Sync for JsError

impl !Sync for Diagnostic

impl !Sync for Program

impl !Sync for Export

impl Sync for MethodSelf

impl !Sync for Import

impl !Sync for ImportModule

impl !Sync for ImportKind

impl !Sync for MethodKind

impl !Sync for Operation

impl !Sync for ImportStatic

impl !Sync for ImportType

impl !Sync for ImportEnum

impl !Sync for Function

impl !Sync for Struct

impl !Sync for StructField

impl !Sync for Enum

impl !Sync for Variant

impl Sync for TypeKind

impl<T> Sync for ShortHash<T>where
    T: Sync,

impl !Sync for JsFuture

impl !Sync for BindgenAttrs

impl<F> Sync for Timeout<F>where
    F: Sync,

impl<S> Sync for TimeoutStream<S>where
    S: Sync,

impl Sync for Delay

impl Sync for Interval

impl Sync for Timer

impl Sync for TimerHandle

impl !Sync for FuncRef

impl !Sync for FuncInstance

impl<'args> !Sync for FuncInvocation<'args>

impl !Sync for GlobalRef

impl<'a> Sync for RuntimeArgs<'a>

impl<'a> !Sync for ImportsBuilder<'a>

impl !Sync for MemoryRef

impl !Sync for ModuleRef

impl !Sync for ExternVal

impl<'a> !Sync for NotStartedModuleRef<'a>

impl Sync for F32

impl Sync for F64

impl !Sync for TableRef

impl Sync for Signature

impl Sync for ValueType

impl Sync for Error

impl Sync for Trap

impl Sync for TrapKind

impl Sync for Error

impl Sync for Module

impl Sync for Error

impl<T> Sync for StackWithLimit<T>where
    T: Sync,

impl Sync for BlockFrame

impl Sync for StartedWith

impl<'a> Sync for Locals<'a>

impl Sync for Error

impl<'a> Sync for BinaryReader<'a>

impl<'a, T> Sync for WasmFuncTypeInputs<'a, T>where
    T: Sync,

impl<'a, T> Sync for WasmFuncTypeOutputs<'a, T>where
    T: Sync,

impl Sync for Encoding

impl Sync for Parser

impl<'a> Sync for Chunk<'a>

impl<'a> Sync for Payload<'a>

impl Sync for AliasKind

impl<'a> Sync for Alias<'a>

impl<'a> Sync for AliasSectionReader<'a>

impl<'a> Sync for ComponentExport<'a>

impl<'a> Sync for ComponentImport<'a>

impl<'a> Sync for ModuleArg<'a>

impl<'a> Sync for ComponentArg<'a>

impl<'a> Sync for Instance<'a>

impl<'a> Sync for InstanceSectionReader<'a>

impl<'a> Sync for ComponentTypeDef<'a>

impl<'a> Sync for ModuleType<'a>

impl<'a> Sync for ComponentType<'a>

impl<'a> Sync for InstanceType<'a>

impl<'a> Sync for ComponentFuncType<'a>

impl<'a> Sync for VariantCase<'a>

impl<'a> Sync for InterfaceType<'a>

impl<'a> Sync for FunctionBody<'a>

impl<'a> Sync for LocalsReader<'a>

impl<'a> Sync for LocalsIterator<'a>

impl<'a> Sync for CodeSectionReader<'a>

impl<'a> Sync for CustomSectionReader<'a>

impl<'a> Sync for Data<'a>

impl<'a> Sync for DataKind<'a>

impl<'a> Sync for DataSectionReader<'a>

impl<'a> Sync for Element<'a>

impl<'a> Sync for ElementKind<'a>

impl<'a> Sync for ElementItems<'a>

impl<'a> Sync for ElementItem<'a>

impl<'a> Sync for ElementItemsReader<'a>

impl<'a> Sync for ElementItemsIterator<'a>

impl<'a> Sync for ElementSectionReader<'a>

impl<'a> Sync for Export<'a>

impl<'a> Sync for ExportSectionReader<'a>

impl<'a> Sync for FunctionSectionReader<'a>

impl<'a> Sync for Global<'a>

impl<'a> Sync for GlobalSectionReader<'a>

impl Sync for TypeRef

impl<'a> Sync for Import<'a>

impl<'a> Sync for ImportSectionReader<'a>

impl<'a> Sync for InitExpr<'a>

impl Sync for LinkingType

impl<'a> Sync for LinkingSectionReader<'a>

impl<'a> Sync for MemorySectionReader<'a>

impl<'a> Sync for Naming<'a>

impl Sync for NameType

impl<'a> Sync for SingleName<'a>

impl<'a> Sync for NamingReader<'a>

impl<'a> Sync for NameMap<'a>

impl<'a> Sync for IndirectNaming<'a>

impl<'a> Sync for IndirectNamingReader<'a>

impl<'a> Sync for IndirectNameMap<'a>

impl<'a> Sync for Name<'a>

impl<'a> Sync for NameSectionReader<'a>

impl Sync for BlockType

impl<'a> Sync for BrTable<'a>

impl Sync for Ieee32

impl Sync for Ieee64

impl Sync for V128

impl<'a> Sync for Operator<'a>

impl<'a> Sync for OperatorsReader<'a>

impl<'a> Sync for OperatorsIterator<'a>

impl<'a> Sync for ProducersFieldValue<'a>

impl<'a> Sync for ProducersField<'a>

impl<'a> Sync for ProducersSectionReader<'a>

impl Sync for RelocType

impl<'a> Sync for SectionCode<'a>

impl Sync for Reloc

impl<'a> Sync for RelocSectionReader<'a>

impl<'a> Sync for TableSectionReader<'a>

impl<'a> Sync for TagSectionReader<'a>

impl Sync for Type

impl Sync for TypeDef

impl Sync for FuncType

impl Sync for TableType

impl Sync for MemoryType

impl Sync for GlobalType

impl Sync for TagKind

impl Sync for TagType

impl<'a> Sync for TypeSectionReader<'a>

impl<R> Sync for SectionIterator<R>where
    R: Sync,

impl<R> Sync for SectionIteratorLimited<R>where
    R: Sync,

impl<T> Sync for FuncValidator<T>where
    T: Sync,

impl Sync for TypeId

impl Sync for TypeDef

impl Sync for EntityType

impl Sync for ModuleType

impl Sync for VariantCase

impl Sync for RecordType

impl Sync for VariantType

impl Sync for TupleType

impl Sync for UnionType

impl Sync for Types

impl Sync for Validator

impl<'a> Sync for ValidPayload<'a>

impl<Params, Results> Sync for TypedFunc<Params, Results>

impl Sync for Func

impl<'a, T> Sync for Caller<'a, T>where
    T: Sync,

impl Sync for Config

impl Sync for Strategy

impl Sync for OptLevel

impl Sync for Engine

impl Sync for Extern

impl Sync for Global

impl Sync for Table

impl<'instance> Sync for Export<'instance>

impl Sync for Instance

impl<T> Sync for InstancePre<T>

impl Sync for StoreLimits

impl<T> Sync for Linker<T>

impl Sync for Memory

impl Sync for FrameInfo

impl Sync for FrameSymbol

impl Sync for Module

impl Sync for ExternRef

impl<'a, T> Sync for StoreContext<'a, T>where
    T: Sync,

impl<'a, T> Sync for StoreContextMut<'a, T>where
    T: Sync,

impl<T> Sync for Store<T>where
    T: Sync,

impl Sync for CallHook

impl Sync for Trap

impl Sync for TrapCode

impl Sync for Mutability

impl Sync for ValType

impl Sync for ExternType

impl Sync for FuncType

impl Sync for GlobalType

impl Sync for TableType

impl Sync for MemoryType

impl<'module> Sync for ImportType<'module>

impl<'module> Sync for ExportType<'module>

impl Sync for Val

impl Sync for CacheConfig

impl<'config> Sync for ModuleCacheEntry<'config>

impl Sync for FilePos

impl Sync for Trampoline

impl Sync for Setting

impl Sync for SettingKind

impl Sync for FlagValue

impl Sync for MemoryStyle

impl Sync for MemoryPlan

impl<'a> !Sync for InitMemory<'a>

impl Sync for TableStyle

impl Sync for TablePlan

impl Sync for ModuleType

impl Sync for Module

impl Sync for Initializer

impl<'a, 'data> Sync for ModuleEnvironment<'a, 'data>

impl<'data> Sync for ModuleTranslation<'data>

impl<'a> Sync for FunctionBodyData<'a>

impl<'a> Sync for DebugInfoData<'a>

impl<'a> Sync for NameSection<'a>

impl Sync for ModuleTypes

impl Sync for StackMap

impl Sync for TrapCode

impl Sync for Tunables

impl<P> Sync for VMOffsets<P>where
    P: Sync,

impl Sync for HostPtr

impl<P> Sync for VMOffsetsFields<P>where
    P: Sync,

impl Sync for CodeMemory

impl Sync for SetupError

impl<'a> !Sync for SymbolizeContext<'a>

impl Sync for VTuneAgent

impl Sync for RecordId

impl Sync for DebugEntry

impl Sync for FileHeader

impl Sync for JitDumpFile

impl Sync for Export

impl<'a> Sync for Imports<'a>

impl !Sync for StorePtr

impl Sync for LinkError

impl Sync for Memory

impl Sync for Mmap

impl Sync for MmapVec

impl Sync for Table

impl !Sync for TlsRestore

impl Sync for Trap

impl Sync for VMContext

impl Sync for ValRaw

impl Sync for MemoryImage

impl Sync for WasmError

impl Sync for WasmType

impl Sync for FuncIndex

impl Sync for TableIndex

impl Sync for GlobalIndex

impl Sync for MemoryIndex

impl Sync for DataIndex

impl Sync for ElemIndex

impl Sync for TypeIndex

impl Sync for TagIndex

impl Sync for EntityIndex

impl Sync for EntityType

impl Sync for Global

impl Sync for GlobalInit

impl Sync for Table

impl Sync for Memory

impl Sync for Tag

impl<'a> Sync for EndEntityCert<'a>

impl Sync for Error

impl Sync for DnsName

impl<'a> Sync for DnsNameRef<'a>

impl Sync for Time

impl<'a> Sync for TrustAnchor<'a>

impl<'a> Sync for TlsServerTrustAnchors<'a>

impl<'a> Sync for TlsClientTrustAnchors<'a>

impl Sync for WndLocation

impl Sync for Ancestry

impl Sync for Westmint

impl Sync for Encointer

impl Sync for Collectives

impl Sync for XcmConfig

impl Sync for BaseFilter

impl Sync for Version

impl Sync for SS58Prefix

impl Sync for MaxLocks

impl Sync for MaxReserves

impl Sync for Period

impl Sync for Offset

impl Sync for SessionKeys

impl Sync for SignedPhase

impl Sync for RewardCurve

impl Sync for MaxKeys

impl Sync for DepositBase

impl Sync for MaxFriends

impl Sync for MaxProxies

impl Sync for MaxPending

impl Sync for ProxyType

impl Sync for ParaDeposit

impl Sync for LeasePeriod

impl Sync for CrowdloanId

impl Sync for Runtime

impl Sync for Event

impl !Sync for Origin

impl Sync for PalletInfo

impl Sync for Call

impl Sync for RuntimeApi

impl Sync for WeightToFee

impl<I> Sync for Bidi<I>where
    I: Sync,

impl Sync for Const

impl Sync for Mut

impl<Inner> Sync for Frozen<Inner>where
    Inner: Sync,

impl<M, T> !Sync for Address<M, T>

impl<T> Sync for FmtBinary<T>where
    T: Sync,

impl<T> Sync for FmtDisplay<T>where
    T: Sync,

impl<T> Sync for FmtList<T>where
    T: Sync,

impl<T> Sync for FmtLowerExp<T>where
    T: Sync,

impl<T> Sync for FmtLowerHex<T>where
    T: Sync,

impl<T> Sync for FmtOctal<T>where
    T: Sync,

impl<T> Sync for FmtPointer<T>where
    T: Sync,

impl<T> Sync for FmtUpperExp<T>where
    T: Sync,

impl<T> Sync for FmtUpperHex<T>where
    T: Sync,

impl Sync for PublicKey

impl Sync for NetworkId

impl Sync for BodyId

impl Sync for BodyPart

impl Sync for Junction

impl Sync for MultiAsset

impl<Call> Sync for Order<Call>where
    Call: Sync,

impl Sync for Error

impl Sync for Outcome

impl Sync for OriginKind

impl Sync for Response

impl<Call> Sync for Xcm<Call>where
    Call: Sync,

impl Sync for Junction

impl Sync for AssetId

impl Sync for Fungibility

impl Sync for MultiAsset

impl Sync for MultiAssets

impl Sync for Parent

impl Sync for ParentThen

impl Sync for Ancestor

impl Sync for Junctions

impl<Call> Sync for Order<Call>where
    Call: Sync,

impl Sync for Error

impl Sync for Outcome

impl Sync for Response

impl<Call> Sync for Xcm<Call>where
    Call: Sync,

impl Sync for Error

impl Sync for Outcome

impl Sync for SendError

impl<Call> Sync for Xcm<Call>where
    Call: Sync,

impl Sync for Response

impl Sync for WeightLimit

impl<Call> Sync for Instruction<Call>where
    Call: Sync,

impl<T> Sync for DoubleEncoded<T>where
    T: Sync,

impl Sync for Unsupported

impl<Call> Sync for VersionedXcm<Call>where
    Call: Sync,

impl Sync for AlwaysV0

impl Sync for AlwaysV1

impl Sync for AlwaysV2

impl<Network, AccountId> Sync for Account32Hash<Network, AccountId>where
    AccountId: Sync,
    Network: Sync,

impl<AccountId> Sync for ParentIsPreset<AccountId>where
    AccountId: Sync,

impl<ParaId, AccountId> Sync for ChildParachainConvertsVia<ParaId, AccountId>where
    AccountId: Sync,
    ParaId: Sync,

impl<ParaId, AccountId> Sync for SiblingParachainConvertsVia<ParaId, AccountId>where
    AccountId: Sync,
    ParaId: Sync,

impl<Network, AccountId> Sync for AccountId32Aliases<Network, AccountId>where
    AccountId: Sync,
    Network: Sync,

impl<Network, AccountId> Sync for AccountKey20Aliases<Network, AccountId>where
    AccountId: Sync,
    Network: Sync,

impl<Ancestry> Sync for LocationInverter<Ancestry>where
    Ancestry: Sync,

impl<LocationConverter, Origin> Sync for SovereignSignedViaLocation<LocationConverter, Origin>where
    LocationConverter: Sync,
    Origin: Sync,

impl<Origin> Sync for ParentAsSuperuser<Origin>where
    Origin: Sync,

impl<ParaId, Origin> Sync for ChildSystemParachainAsSuperuser<ParaId, Origin>where
    Origin: Sync,
    ParaId: Sync,

impl<ParaId, Origin> Sync for SiblingSystemParachainAsSuperuser<ParaId, Origin>where
    Origin: Sync,
    ParaId: Sync,

impl<ParachainOrigin, Origin> Sync for ChildParachainAsNative<ParachainOrigin, Origin>where
    Origin: Sync,
    ParachainOrigin: Sync,

impl<ParachainOrigin, Origin> Sync for SiblingParachainAsNative<ParachainOrigin, Origin>where
    Origin: Sync,
    ParachainOrigin: Sync,

impl<RelayOrigin, Origin> Sync for RelayChainAsNative<RelayOrigin, Origin>where
    Origin: Sync,
    RelayOrigin: Sync,

impl<Network, Origin> Sync for SignedAccountId32AsNative<Network, Origin>where
    Network: Sync,
    Origin: Sync,

impl<Network, Origin> Sync for SignedAccountKey20AsNative<Network, Origin>where
    Network: Sync,
    Origin: Sync,

impl<Origin, Conversion> Sync for EnsureXcmOrigin<Origin, Conversion>where
    Conversion: Sync,
    Origin: Sync,

impl<Origin, AccountId, Network> Sync for SignedToAccountId32<Origin, AccountId, Network>where
    AccountId: Sync,
    Network: Sync,
    Origin: Sync,

impl<Origin, COrigin, Body> Sync for BackingToPlurality<Origin, COrigin, Body>where
    Body: Sync,
    COrigin: Sync,
    Origin: Sync,

impl<T> Sync for AllowTopLevelPaidExecutionFrom<T>where
    T: Sync,

impl<T> Sync for AllowUnpaidExecutionFrom<T>where
    T: Sync,

impl<ParaId> Sync for IsChildSystemParachain<ParaId>where
    ParaId: Sync,

impl<ResponseHandler> Sync for AllowKnownQueryResponses<ResponseHandler>where
    ResponseHandler: Sync,

impl<T> Sync for AllowSubscriptionsFrom<T>where
    T: Sync,

impl<Currency, Matcher, AccountIdConverter, AccountId, CheckedAccount> Sync for CurrencyAdapter<Currency, Matcher, AccountIdConverter, AccountId, CheckedAccount>where
    AccountId: Sync,
    AccountIdConverter: Sync,
    CheckedAccount: Sync,
    Currency: Sync,
    Matcher: Sync,

impl<Prefix, AssetId, ConvertAssetId> Sync for AsPrefixedGeneralIndex<Prefix, AssetId, ConvertAssetId>where
    AssetId: Sync,
    ConvertAssetId: Sync,
    Prefix: Sync,

impl<AssetId, Balance, ConvertAssetId, ConvertBalance> Sync for ConvertedConcreteAssetId<AssetId, Balance, ConvertAssetId, ConvertBalance>where
    AssetId: Sync,
    Balance: Sync,
    ConvertAssetId: Sync,
    ConvertBalance: Sync,

impl<AssetId, Balance, ConvertAssetId, ConvertBalance> Sync for ConvertedAbstractAssetId<AssetId, Balance, ConvertAssetId, ConvertBalance>where
    AssetId: Sync,
    Balance: Sync,
    ConvertAssetId: Sync,
    ConvertBalance: Sync,

impl<Assets, Matcher, AccountIdConverter, AccountId> Sync for FungiblesTransferAdapter<Assets, Matcher, AccountIdConverter, AccountId>where
    AccountId: Sync,
    AccountIdConverter: Sync,
    Assets: Sync,
    Matcher: Sync,

impl<Assets, Matcher, AccountIdConverter, AccountId, CheckAsset, CheckingAccount> Sync for FungiblesMutateAdapter<Assets, Matcher, AccountIdConverter, AccountId, CheckAsset, CheckingAccount>where
    AccountId: Sync,
    AccountIdConverter: Sync,
    Assets: Sync,
    CheckAsset: Sync,
    CheckingAccount: Sync,
    Matcher: Sync,

impl<Assets, Matcher, AccountIdConverter, AccountId, CheckAsset, CheckingAccount> Sync for FungiblesAdapter<Assets, Matcher, AccountIdConverter, AccountId, CheckAsset, CheckingAccount>where
    AccountId: Sync,
    AccountIdConverter: Sync,
    Assets: Sync,
    CheckAsset: Sync,
    CheckingAccount: Sync,
    Matcher: Sync,

impl<T, C, M> Sync for FixedWeightBounds<T, C, M>where
    C: Sync,
    M: Sync,
    T: Sync,

impl<W, C, M> Sync for WeightInfoBounds<W, C, M>where
    C: Sync,
    M: Sync,
    W: Sync,

impl<T, R> Sync for FixedRateOfConcreteFungible<T, R>where
    R: Sync,
    T: Sync,

impl<T, R> Sync for FixedRateOfFungible<T, R>where
    R: Sync,
    T: Sync,

impl<WeightToFee, AssetId, AccountId, Currency, OnUnbalanced> Sync for UsingComponents<WeightToFee, AssetId, AccountId, Currency, OnUnbalanced>where
    AccountId: Sync,
    AssetId: Sync,
    Currency: Sync,
    OnUnbalanced: Sync,
    WeightToFee: Sync,
    <Currency as Currency<AccountId>>::Balance: Sync,

impl<T> Sync for IsConcrete<T>where
    T: Sync,

impl<T> Sync for IsAbstract<T>where
    T: Sync,

impl Sync for NativeAsset

impl<T> Sync for Case<T>where
    T: Sync,

impl Sync for Identity

impl Sync for JustTry

impl Sync for Encoded

impl Sync for Decoded

impl Sync for Error

impl Sync for Assets

impl<Config> Sync for XcmExecutor<Config>where
    Config: Sync,
    <Config as Config>::Call: Sync,
    <Config as Config>::Trader: Sync,

impl Sync for StreamId

impl Sync for Control

impl Sync for Stream

impl Sync for Packet

impl Sync for Mode

impl<T> Sync for Connection<T>where
    T: Sync,

impl Sync for Config

impl<Z> Sync for Zeroizing<Z>where
    Z: Sync,

impl<'a> !Sync for Compressor<'a>

impl<'a> !Sync for Decompressor<'a>

impl<'a> Sync for EncoderDictionary<'a>

impl<'a> Sync for DecoderDictionary<'a>

impl<'a, R> !Sync for Decoder<'a, R>

impl<'a, R> !Sync for Encoder<'a, R>

impl<'a, W> !Sync for Encoder<'a, W>

impl<'a, W> !Sync for Decoder<'a, W>

impl<'a, W, F = Box<dyn FnMut(Result<W, Error>) + Send + 'static, Global>> !Sync for AutoFinishEncoder<'a, W, F>

impl<'a, W, F = Box<dyn FnMut(Result<(), Error>) + Send + 'static, Global>> !Sync for AutoFlushDecoder<'a, W, F>

impl<R, D> Sync for Reader<R, D>where
    D: Sync,
    R: Sync,

impl<W, D> Sync for Writer<W, D>where
    D: Sync,
    W: Sync,

impl Sync for NoOp

impl Sync for Status

impl<'a> !Sync for Decoder<'a>

impl<'a> !Sync for Encoder<'a>

impl<'a> !Sync for CCtx<'a>

impl<'a> !Sync for DCtx<'a>

impl<'a> Sync for InBuffer<'a>

impl<'a, C: ?Sized> Sync for OutBuffer<'a, C>where
    C: Sync,

impl Sync for CParameter

impl Sync for DParameter

impl Sync for ZSTD_CCtx_s

impl Sync for ZSTD_DCtx_s

impl Sync for ZSTD_bounds