rustc_data_structures::sync

Trait Sync

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.

A shorter overview of how Sync and Send relate to referencing:

  • &T is Send if and only if T is Sync
  • &mut T is Send if and only if T is Send
  • &T and &mut T are Sync if and only if T is Sync

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§

1.0.0 · Source§

impl !Sync for Arguments<'_>

Source§

impl !Sync for LocalWaker

1.26.0 · Source§

impl !Sync for Args

1.26.0 · Source§

impl !Sync for ArgsOs

Source§

impl Sync for OwnedSlice

1.6.0 · Source§

impl Sync for alloc::string::Drain<'_>

Source§

impl Sync for Bytes<'_>

1.34.0 · Source§

impl Sync for AtomicI8

1.34.0 · Source§

impl Sync for AtomicI16

1.34.0 · Source§

impl Sync for AtomicI32

1.34.0 · Source§

impl Sync for AtomicI64

1.0.0 · Source§

impl Sync for AtomicIsize

1.34.0 · Source§

impl Sync for AtomicU8

1.34.0 · Source§

impl Sync for AtomicU16

1.36.0 · Source§

impl Sync for Waker

Source§

impl Sync for Select<'_>

Source§

impl Sync for Collector

Source§

impl Sync for Unparker

Source§

impl Sync for Scope<'_>

Source§

impl Sync for GuardNoSend

1.0.0 · Source§

impl Sync for AtomicBool

1.34.0 · Source§

impl Sync for AtomicU32

1.34.0 · Source§

impl Sync for AtomicU64

1.0.0 · Source§

impl Sync for AtomicUsize

1.44.0 · Source§

impl<'a> Sync for IoSlice<'a>

1.44.0 · Source§

impl<'a> Sync for IoSliceMut<'a>

Source§

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,

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

impl<Dyn> Sync for DynMetadata<Dyn>
where Dyn: ?Sized,

Source§

impl<K, V, A> Sync for RustcOccupiedEntry<'_, K, V, A>
where K: Sync, V: Sync, A: Allocator + Sync,

Source§

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

Source§

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

Source§

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

Source§

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

Source§

impl<P, T, const CP: bool> Sync for CopyTaggedPtr<P, T, CP>
where P: Sync + Pointer, T: Sync + Tag,

Source§

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

Source§

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

Source§

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

Source§

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

Source§

impl<R, T> Sync for lock_api::rwlock::RwLockReadGuard<'_, R, T>
where R: RawRwLock + Sync, T: Sync + ?Sized,

Source§

impl<R, T> Sync for lock_api::rwlock::RwLockWriteGuard<'_, R, T>
where R: RawRwLock + Sync, T: Sync + ?Sized,

1.0.0 · Source§

impl<T> !Sync for *const T
where T: ?Sized,

1.0.0 · Source§

impl<T> !Sync for *mut T
where T: ?Sized,

1.70.0 · Source§

impl<T> !Sync for OnceCell<T>

1.0.0 · Source§

impl<T> !Sync for Cell<T>
where T: ?Sized,

1.0.0 · Source§

impl<T> !Sync for RefCell<T>
where T: ?Sized,

1.0.0 · Source§

impl<T> !Sync for UnsafeCell<T>
where T: ?Sized,

1.25.0 · Source§

impl<T> !Sync for NonNull<T>
where T: ?Sized,

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

1.0.0 · Source§

impl<T> !Sync for std::sync::mpsc::Receiver<T>

Source§

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

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

1.0.0 · Source§

impl<T> Sync for alloc::collections::linked_list::Iter<'_, T>
where T: Sync,

1.0.0 · Source§

impl<T> Sync for alloc::collections::linked_list::IterMut<'_, T>
where T: Sync,

Source§

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

1.28.0 · Source§

impl<T> Sync for NonZero<T>

1.31.0 · Source§

impl<T> Sync for ChunksExactMut<'_, T>
where T: Sync,

1.0.0 · Source§

impl<T> Sync for ChunksMut<'_, T>
where T: Sync,

1.0.0 · Source§

impl<T> Sync for core::slice::iter::Iter<'_, T>
where T: Sync,

1.0.0 · Source§

impl<T> Sync for core::slice::iter::IterMut<'_, T>
where T: Sync,

1.31.0 · Source§

impl<T> Sync for RChunksExactMut<'_, T>
where T: Sync,

1.31.0 · Source§

impl<T> Sync for RChunksMut<'_, T>
where T: Sync,

1.0.0 · Source§

impl<T> Sync for AtomicPtr<T>

Source§

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

Source§

impl<T> Sync for std::sync::mpmc::Receiver<T>
where T: Send,

Source§

impl<T> Sync for std::sync::mpmc::Sender<T>
where T: Send,

1.72.0 · Source§

impl<T> Sync for std::sync::mpsc::Sender<T>
where T: Send,

Source§

impl<T> Sync for std::sync::mutex::MappedMutexGuard<'_, T>
where T: Sync + ?Sized,

1.0.0 · Source§

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

1.19.0 · Source§

impl<T> Sync for std::sync::mutex::MutexGuard<'_, T>
where T: Sync + ?Sized,

Source§

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

Source§

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

Source§

impl<T> Sync for std::sync::rwlock::MappedRwLockReadGuard<'_, T>
where T: Sync + ?Sized,

Source§

impl<T> Sync for std::sync::rwlock::MappedRwLockWriteGuard<'_, T>
where T: Sync + ?Sized,

1.0.0 · Source§

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

1.23.0 · Source§

impl<T> Sync for std::sync::rwlock::RwLockReadGuard<'_, T>
where T: Sync + ?Sized,

1.23.0 · Source§

impl<T> Sync for std::sync::rwlock::RwLockWriteGuard<'_, T>
where T: Sync + ?Sized,

1.29.0 · Source§

impl<T> Sync for JoinHandle<T>

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

impl<T> Sync for rayon_core::worker_local::WorkerLocal<T>
where T: Send,

We prevent concurrent access to the underlying value in the Deref impl, thus any values safe to send across threads can be used with WorkerLocal.

Source§

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

1.70.0 · Source§

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

1.0.0 · Source§

impl<T, A> !Sync for Rc<T, A>
where A: Allocator, T: ?Sized,

1.4.0 · Source§

impl<T, A> !Sync for alloc::rc::Weak<T, A>
where A: Allocator, T: ?Sized,

Source§

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

Source§

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

1.0.0 · Source§

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

1.6.0 · Source§

impl<T, A> Sync for alloc::collections::vec_deque::drain::Drain<'_, T, A>
where T: Sync, A: Allocator + Sync,

1.6.0 · Source§

impl<T, A> Sync for alloc::vec::drain::Drain<'_, T, A>
where T: Sync, A: Sync + Allocator,

1.0.0 · Source§

impl<T, A> Sync for alloc::vec::into_iter::IntoIter<T, A>
where T: Sync, A: Allocator + Sync,

Source§

impl<T, A> Sync for hashbrown::table::OccupiedEntry<'_, T, A>
where T: Sync, A: Sync + Allocator,

Source§

impl<T, A> Sync for Box<T, A>
where A: Allocator + Sync, T: Sync + ?Sized,

Source§

impl<T, A> Sync for allocator_api2::stable::vec::drain::Drain<'_, T, A>
where T: Sync, A: Sync + Allocator,

Source§

impl<T, A> Sync for allocator_api2::stable::vec::into_iter::IntoIter<T, A>
where T: Sync, A: Allocator + Sync,

Source§

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

Source§

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

Source§

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

Source§

impl<T, A> Sync for hashbrown::table::OccupiedEntry<'_, T, A>
where T: Sync, A: Sync + Allocator,

1.0.0 · Source§

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

1.4.0 · Source§

impl<T, A> Sync for rustc_data_structures::sync::Weak<T, A>
where T: Sync + Send + ?Sized, A: Allocator + Sync,

1.80.0 · Source§

impl<T, F> Sync for LazyLock<T, F>
where T: Sync + Send, F: Send,

Source§

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

Source§

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

Source§

impl<T: DynSync> Sync for FromDyn<T>

Source§

impl<T: Send> Sync for rustc_data_structures::sync::worker_local::WorkerLocal<T>

impl<T> Sync for Interned<T>

impl Sync for ThinBuffer

impl Sync for ThinData

impl Sync for ModuleLlvm

impl<'tcx> Sync for GenericArg<'tcx>
where &'tcx (Ty<'tcx>, Region<'tcx>, Const<'tcx>): Sync,

impl<'tcx> Sync for Term<'tcx>
where &'tcx (Ty<'tcx>, Const<'tcx>): Sync,

impl<H: Sync, T: Sync> Sync for RawList<H, T>

Auto implementors§

§

impl !Sync for RegistryId

§

impl !Sync for ThreadData

§

impl !Sync for ModeUnion

§

impl Sync for NodeStatus

§

impl Sync for rustc_data_structures::obligation_forest::NodeState

§

impl Sync for TimePassesFormat

§

impl Sync for Mode

§

impl Sync for BaseNString

§

impl Sync for Fingerprint

§

impl Sync for PackedFingerprint

§

impl Sync for rustc_data_structures::flock::linux::Lock

§

impl Sync for FxHasher

§

impl Sync for PreorderIndex

§

impl Sync for Time

§

impl Sync for Direction

§

impl Sync for EdgeIndex

§

impl Sync for NodeIndex

§

impl Sync for CycleDetector

§

impl Sync for PrivateZst

§

impl Sync for Client

§

impl Sync for Mmap

§

impl Sync for MmapMut

§

impl Sync for ObligationTreeId

§

impl Sync for Pu128

§

impl Sync for EventFilter

§

impl Sync for EventId

§

impl Sync for QueryInvocationId

§

impl Sync for SelfProfiler

§

impl Sync for SelfProfilerRef

§

impl Sync for VerboseInfo

§

impl Sync for SmallCStr

§

impl Sync for Hash64

§

impl Sync for Hash128

§

impl Sync for HashingControls

§

impl Sync for SipHasher128Hash

§

impl Sync for FatalErrorMarker

§

impl Sync for Svh

§

impl Sync for MaybeTempDir

§

impl Sync for rustc_data_structures::transitive_relation::Edge

§

impl Sync for Index

§

impl Sync for NoUndo

§

impl Sync for rustc_data_structures::undo_log::Snapshot

§

impl Sync for Unhasher

§

impl Sync for NoError

§

impl Sync for ParallelGuard

§

impl Sync for Registry

§

impl Sync for RegistryData

§

impl<'a> Sync for JsonTimePassesEntry<'a>

§

impl<'a> Sync for TimingGuard<'a>

§

impl<'a> Sync for VerboseTimingGuard<'a>

§

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

§

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

§

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

§

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

§

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

§

impl<'a, T, F> Sync for ExtractIf<'a, T, F>
where F: Sync, T: Sync,

§

impl<'c, G, S, A, F> Sync for SccsConstruction<'c, G, S, A, F>
where F: Sync, G: Sync, <G as DirectedGraph>::Node: Sync, S: Sync, A: Sync,

§

impl<'g, N, E> Sync for AdjacentEdges<'g, N, E>
where N: Sync, E: Sync,

§

impl<'g, N, E> Sync for DepthFirstTraversal<'g, N, E>
where N: Sync, E: Sync,

§

impl<'graph, G> Sync for TriColorDepthFirstSearch<'graph, G>
where G: Sync + ?Sized, <G as DirectedGraph>::Node: Sync,

§

impl<'p> Sync for EventArgRecorder<'p>

§

impl<A> Sync for SccDetails<A>
where A: Sync,

§

impl<D> Sync for rustc_data_structures::snapshot_vec::UndoLog<D>

§

impl<D, V, L> Sync for SnapshotVec<D, V, L>
where V: Sync, L: Sync, D: Sync,

§

impl<E> Sync for rustc_data_structures::graph::implementation::Edge<E>
where E: Sync,

§

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

§

impl<G> Sync for DepthFirstSearch<G>
where G: Sync, <G as DirectedGraph>::Node: Sync,

§

impl<I, K, V> Sync for SortedIndexMultiMap<I, K, V>
where I: Sync, K: Sync, V: Sync,

§

impl<I, T> Sync for AppendOnlyIndexVec<I, T>

§

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

§

impl<K> Sync for VarValue<K>
where K: Sync, <K as UnifyKey>::Value: Sync,

§

impl<K, V> Sync for rustc_data_structures::snapshot_map::UndoLog<K, V>
where K: Sync, V: Sync,

§

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

§

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

§

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

§

impl<K, V, L> Sync for InPlace<K, V, L>
where V: Sync, L: Sync, K: Sync,

§

impl<K, V, M, L> Sync for SnapshotMap<K, V, M, L>
where M: Sync, L: Sync, K: Sync, V: Sync,

§

impl<N> Sync for Inner<N>
where N: Sync,

§

impl<N> Sync for rustc_data_structures::graph::implementation::Node<N>
where N: Sync,

§

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

§

impl<N, E> Sync for Graph<N, E>
where N: Sync, E: Sync,

§

impl<N, S, A> Sync for rustc_data_structures::graph::scc::NodeState<N, S, A>
where A: Sync, S: Sync, N: Sync,

§

impl<N, S, A> Sync for Sccs<N, S, A>
where S: Sync, A: Sync,

§

impl<N, const BR: bool> Sync for VecGraph<N, BR>
where N: Sync,

§

impl<Node> Sync for Kind<Node>
where Node: Sync,

§

impl<Node> Sync for Dominators<Node>
where Node: Sync,

§

impl<O> !Sync for rustc_data_structures::obligation_forest::Node<O>

§

impl<O> !Sync for ObligationForest<O>

§

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

§

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

§

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

§

impl<P, T, const COMPARE_PACKED: bool> Sync for TaggedPtr<P, T, COMPARE_PACKED>
where P: Sync, T: Sync,

§

impl<S> Sync for rustc_data_structures::snapshot_vec::Snapshot<S>
where S: Sync,

§

impl<S> Sync for rustc_data_structures::unify::Snapshot<S>
where <S as UnificationStore>::Snapshot: Sync, S: Sync,

§

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

§

impl<S, A> Sync for WalkReturn<S, A>
where A: Sync, S: Sync,

§

impl<S, A> Sync for SccData<S, A>
where S: Sync, A: Sync,

§

impl<T> !Sync for Sharded<T>

§

impl<T> !Sync for FreezeLock<T>

§

impl<T> !Sync for rustc_data_structures::sync::lock::Lock<T>

§

impl<T> !Sync for MTLock<T>

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<T> Sync for rustc_data_structures::sync::RwLock<T>
where T: Send + Sync,

§

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

§

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

§

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

§

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

impl !Sync for Config

impl !Sync for Build

impl !Sync for Cache

impl Sync for EditorKind

impl Sync for Profile

impl Sync for SourceType

impl Sync for Tool

impl Sync for ToolState

impl Sync for Alias

impl Sync for Kind

impl Sync for PathSet

impl Sync for DryRun

impl Sync for LldMode

impl Sync for ReplaceOpt

impl Sync for RustcLto

impl Sync for StringOrInt

impl Sync for Color

impl Sync for Subcommand

impl Sync for Warnings

impl Sync for CLang

impl Sync for DocTests

impl Sync for GitRepo

impl Sync for Mode

impl Sync for Language

impl Sync for GitInfo

impl Sync for OutputMode

impl Sync for LldThreads

impl Sync for Message

impl Sync for TestMessage

impl Sync for OverlayKind

impl Sync for Bootstrap

impl Sync for CargoMiri

impl Sync for Clippy

impl Sync for Miri

impl Sync for Rls

impl Sync for Rustc

impl Sync for Rustdoc

impl Sync for Rustfmt

impl Sync for Std

impl Sync for CleanAll

impl Sync for Rustc

impl Sync for Std

impl Sync for Bootstrap

impl Sync for BuildHelper

impl Sync for CargoMiri

impl Sync for Clippy

impl Sync for Compiletest

impl Sync for Jsondocck

impl Sync for Jsondoclint

impl Sync for LintDocs

impl Sync for Miri

impl Sync for OptDist

impl Sync for Rls

impl Sync for Rustc

impl Sync for Rustdoc

impl Sync for Rustfmt

impl Sync for Std

impl Sync for Tidy

impl Sync for Assemble

impl Sync for Rustc

impl Sync for RustcLink

impl Sync for Std

impl Sync for StdLink

impl Sync for Sysroot

impl Sync for Analysis

impl Sync for Bootstrap

impl Sync for Cargo

impl Sync for Clippy

impl Sync for Docs

impl Sync for Extended

impl Sync for JsonDocs

impl Sync for LlvmTools

impl Sync for Mingw

impl Sync for Miri

impl Sync for Rls

impl Sync for RustDev

impl Sync for Rustc

impl Sync for RustcDev

impl Sync for RustcDocs

impl Sync for Rustfmt

impl Sync for Src

impl Sync for Std

impl Sync for Bootstrap

impl Sync for BuildHelper

impl Sync for Cargo

impl Sync for CargoBook

impl Sync for Clippy

impl Sync for ClippyBook

impl Sync for Compiletest

impl Sync for ErrorIndex

impl Sync for Miri

impl Sync for Nomicon

impl Sync for Reference

impl Sync for Releases

impl Sync for Rustc

impl Sync for RustcBook

impl Sync for Rustdoc

impl Sync for RustdocBook

impl Sync for Rustfmt

impl Sync for Standalone

impl Sync for Std

impl Sync for StyleGuide

impl Sync for TheBook

impl Sync for Tidy

impl Sync for Gcc

impl Sync for Meta

impl Sync for Cargo

impl Sync for Clippy

impl Sync for Docs

impl Sync for LlvmTools

impl Sync for Miri

impl Sync for Rustc

impl Sync for Rustfmt

impl Sync for Src

impl Sync for Std

impl Sync for CrtBeginEnd

impl Sync for Enzyme

impl Sync for LdFlags

impl Sync for Libunwind

impl Sync for Lld

impl Sync for Llvm

impl Sync for LlvmResult

impl Sync for Meta

impl Sync for Sanitizers

impl Sync for BumpStage0

impl Sync for Miri

impl Sync for Editor

impl Sync for Hook

impl Sync for Link

impl Sync for Assembly

impl Sync for BookTest

impl Sync for Bootstrap

impl Sync for Cargo

impl Sync for CargoMiri

impl Sync for Cargotest

impl Sync for Clippy

impl Sync for Codegen

impl Sync for CodegenGCC

impl Sync for Compiletest

impl Sync for Coverage

impl Sync for CoverageMap

impl Sync for CoverageRun

impl Sync for Crashes

impl Sync for Crate

impl Sync for Debuginfo

impl Sync for Distcheck

impl Sync for ErrorIndex

impl Sync for HtmlCheck

impl Sync for Incremental

impl Sync for Linkcheck

impl Sync for LintDocs

impl Sync for MirOpt

impl Sync for Miri

impl Sync for Nomicon

impl Sync for Pretty

impl Sync for Reference

impl Sync for RunMake

impl Sync for RustcBook

impl Sync for RustcGuide

impl Sync for Rustdoc

impl Sync for RustdocBook

impl Sync for RustdocGUI

impl Sync for RustdocJson

impl Sync for RustdocUi

impl Sync for Rustfmt

impl Sync for TestHelpers

impl Sync for TheBook

impl Sync for Tidy

impl Sync for TierCheck

impl Sync for Ui

impl Sync for UiFullDeps

impl Sync for BumpStage0

impl Sync for Cargo

impl Sync for CargoClippy

impl Sync for CargoMiri

impl Sync for CargoTest

impl Sync for Cargofmt

impl Sync for Clippy

impl Sync for Compiletest

impl Sync for ErrorIndex

impl Sync for HtmlChecker

impl Sync for JsonDocCk

impl Sync for JsonDocLint

impl Sync for Linkchecker

impl Sync for LintDocs

impl Sync for LldWrapper

impl Sync for Miri

impl Sync for Rls

impl Sync for Rustbook

impl Sync for RustcPerf

impl Sync for Rustdoc

impl Sync for Rustfmt

impl Sync for Tidy

impl Sync for ToolBuild

impl Sync for RepoState

impl Sync for Vendor

impl Sync for Cargo

impl Sync for HostFlags

impl Sync for Rustflags

impl Sync for TaskPath

impl Sync for Build

impl Sync for Dist

impl Sync for Install

impl Sync for Llvm

impl Sync for Rust

impl Sync for Target

impl Sync for TomlConfig

impl Sync for TomlTarget

impl Sync for Flags

impl Sync for Dependency

impl Sync for Output

impl Sync for Package

impl Sync for Target

impl Sync for Finder

impl Sync for Compiler

impl Sync for Crate

impl Sync for Interner

impl Sync for ChangeInfo

impl Sync for Info

impl Sync for HashStamp

impl Sync for TimeIt

impl Sync for TestOutcome

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

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

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

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

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

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

impl<'a> Sync for CargoMessage<'a>

impl<'a> Sync for Outcome<'a>

impl<'a> Sync for CargoTarget<'a>

impl<P> Sync for RustbookSrc<P>
where P: Sync,

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

impl Sync for CiEnv

impl Sync for JsonNode

impl Sync for TestOutcome

impl Sync for Group

impl Sync for DropBomb

impl Sync for JsonRoot

impl Sync for Test

impl Sync for TestSuite

impl Sync for Stage0

impl<'a> Sync for GitConfig<'a>

impl !Sync for ShellOut

impl !Sync for MaybePackage

impl !Sync for MaybePackage

impl !Sync for BuildConfig

impl !Sync for TargetInfo

impl !Sync for Doctest

impl !Sync for UnitOutput

impl !Sync for Job

impl !Sync for Work

impl !Sync for UnitTime

impl !Sync for Unit

impl !Sync for UnitInner

impl !Sync for UnitInterner

impl !Sync for UnitDep

impl !Sync for Manifest

impl !Sync for Package

impl !Sync for PackageInner

impl !Sync for CliFeatures

impl !Sync for Resolve

impl !Sync for DepsFrame

impl !Sync for ResolveOpts

impl !Sync for Shell

impl !Sync for DocOptions

impl !Sync for TestOptions

impl !Sync for FixOptions

impl !Sync for PublishPlan

impl !Sync for TreeOptions

impl !Sync for GitDatabase

impl !Sync for GitShortID

impl !Sync for CacheLocker

impl !Sync for TargetConfig

impl Sync for CompileMode

impl Sync for FileFlavor

impl Sync for Flags

impl Sync for ToolKind

impl Sync for CompileKind

impl Sync for CrateType

impl Sync for Severity

impl Sync for DirtyReason

impl Sync for FsStatus

impl Sync for StaleItem

impl Sync for Artifact

impl Sync for Message

impl Sync for Freshness

impl Sync for Lto

impl Sync for IsArtifact

impl Sync for DepKind

impl Sync for Edition

impl Sync for Status

impl Sync for TargetKind

impl Sync for DebugInfo

impl Sync for Lto

impl Sync for ProfileRoot

impl Sync for Strip

impl Sync for StripInner

impl Sync for Kind

impl Sync for FeaturesFor

impl Sync for HasDevUnits

impl Sync for ColorChoice

impl Sync for TtyWidth

impl Sync for Verbosity

impl Sync for KeyOf

impl Sync for Precise

impl Sync for FilterRule

impl Sync for LibRule

impl Sync for Packages

impl Sync for TestKind

impl Sync for Prefix

impl Sync for Target

impl Sync for Chunk

impl Sync for EdgeKind

impl Sync for Node

impl Sync for RemoteKind

impl Sync for OpenMode

impl Sync for Revision

impl Sync for FastPathRev

impl Sync for MaybeLock

impl Sync for StatusCode

impl Sync for QueryKind

impl Sync for CommandInfo

impl Sync for KeyKind

impl Sync for ConfigValue

impl Sync for JobsConfig

impl Sync for Tool

impl Sync for WhyLoad

impl Sync for Definition

impl Sync for Message

impl Sync for LintLevel

impl Sync for Source

impl Sync for FileType

impl Sync for BuildPlan

impl Sync for Invocation

impl Sync for MetaInfo

impl Sync for Metadata

impl Sync for OutputFile

impl Sync for BuildDeps

impl Sync for BuildOutput

impl Sync for Checksum

impl Sync for After

impl Sync for Fingerprint

impl Sync for Diagnostic

impl Sync for JobId

impl Sync for Layout

impl Sync for Concurrency

impl Sync for Artifact

impl Sync for Dependency

impl Sync for Inner

impl Sync for CliUnstable

impl Sync for Feature

impl Sync for Features

impl Sync for GitFeatures

impl Sync for AutoConfig

impl Sync for GcOpts

impl Sync for BasePaths

impl Sync for GitCheckout

impl Sync for GitDb

impl Sync for ParentId

impl Sync for RegistrySrc

impl Sync for Target

impl Sync for TargetInner

impl Sync for Warnings

impl Sync for PackageId

impl Sync for Profile

impl Sync for Profiles

impl Sync for UnitFor

impl Sync for Patch

impl Sync for FeatureOpts

impl Sync for SourceId

impl Sync for Inner

impl Sync for Summary

impl Sync for CrateSpec

impl Sync for DepOp

impl Sync for Transaction

impl Sync for IgnoreList

impl Sync for NewOptions

impl Sync for Dep

impl Sync for DepKindInfo

impl Sync for ExportInfo

impl Sync for ArchiveFile

impl Sync for GitVcsInfo

impl Sync for VcsInfo

impl Sync for PackageDiff

impl Sync for InstallInfo

impl Sync for FixArgs

impl Sync for FixedCrate

impl Sync for FixedFile

impl Sync for Pattern

impl Sync for Edges

impl Sync for Symbols

impl Sync for Checksum

impl Sync for KnownHost

impl Sync for GitRemote

impl Sync for Headers

impl Sync for Summaries

impl Sync for CacheState

impl Sync for Env

impl Sync for ConfigKey

impl Sync for PathAndArgs

impl Sync for ConfigError

impl Sync for StringList

impl Sync for TermConfig

impl Sync for ValueKey

impl Sync for State

impl Sync for State

impl Sync for CliError

impl Sync for FileLock

impl Sync for Filesystem

impl Sync for Lint

impl Sync for LintGroup

impl Sync for LockServer

impl Sync for HttpTimeout

impl Sync for Format

impl Sync for Throttle

impl Sync for Cache

impl Sync for CacheData

impl Sync for Output

impl Sync for Rustc

impl Sync for Dependency

impl Sync for GitSource

impl Sync for PathSource

impl Sync for DepTable

impl Sync for Manifest

impl Sync for FossilRepo

impl Sync for GitRepo

impl Sync for HgRepo

impl Sync for PijulRepo

impl Sync for CommitInfo

impl Sync for VersionInfo

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

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

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

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

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

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

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

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

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

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

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

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

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

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

impl<'a> Sync for WhyTick<'a>

impl<'a> Sync for RawChunk<'a>

impl<'a> Sync for SerializedUnit<'a>

impl<'a> Sync for SerializedUnitGraph<'a>

impl<'a> Sync for SerializedArtifact<'a>

impl<'a> Sync for SerializedTarget<'a>

impl<'a> Sync for PackageIdStableHash<'a>

impl<'a> Sync for Requirements<'a>

impl<'a> Sync for EncodeState<'a>

impl<'a> Sync for SourceIdAsUrl<'a>

impl<'a> Sync for GetOptions<'a>

impl<'a> Sync for MkOptions<'a>

impl<'a> Sync for Parser<'a>

impl<'a> Sync for VendorOptions<'a>

impl<'a> Sync for SummariesCache<'a>

impl<'a> Sync for IndexPackage<'a>

impl<'a> Sync for RegistryDependency<'a>

impl<'a> Sync for Footer<'a>

impl<'a> Sync for Message<'a>

impl<'a> Sync for ManifestCauses<'a>

impl<'a> Sync for Artifact<'a>

impl<'a> Sync for BuildScript<'a>

impl<'a> Sync for FromCompiler<'a>

impl<'a> Sync for TimingInfo<'a>

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

impl<'a, 'gctx> !Sync for BuildContext<'a, 'gctx>

impl<'a, 'gctx> !Sync for CompilationFiles<'a, 'gctx>

impl<'a, 'gctx> !Sync for BuildRunner<'a, 'gctx>

impl<'a, 'gctx> !Sync for JobState<'a, 'gctx>

impl<'a, 'gctx> !Sync for State<'a, 'gctx>

impl<'a, 'gctx> !Sync for Gc<'a, 'gctx>

impl<'a, 'gctx> !Sync for Downloads<'a, 'gctx>

impl<'a, 'gctx> !Sync for FeatureResolver<'a, 'gctx>

impl<'a, 'gctx> !Sync for UnitGenerator<'a, 'gctx>

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

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

impl<'gctx> !Sync for RustcTargetData<'gctx>

impl<'gctx> !Sync for Compilation<'gctx>

impl<'gctx> !Sync for DiagDedupe<'gctx>

impl<'gctx> !Sync for DrainState<'gctx>

impl<'gctx> !Sync for JobQueue<'gctx>

impl<'gctx> !Sync for Timings<'gctx>

impl<'gctx> !Sync for Download<'gctx>

impl<'gctx> !Sync for PackageSet<'gctx>

impl<'gctx> !Sync for PackageRegistry<'gctx>

impl<'gctx> !Sync for Packages<'gctx>

impl<'gctx> !Sync for Workspace<'gctx>

impl<'gctx> !Sync for CleanContext<'gctx>

impl<'gctx> !Sync for CleanOptions<'gctx>

impl<'gctx> !Sync for CleaningFolderBar<'gctx>

impl<'gctx> !Sync for CleaningPackagesBar<'gctx>

impl<'gctx> !Sync for InstallablePackage<'gctx>

impl<'gctx> !Sync for PackageOpts<'gctx>

impl<'gctx> !Sync for PublishOpts<'gctx>

impl<'gctx> !Sync for WorkspaceResolve<'gctx>

impl<'gctx> !Sync for SourceConfigMap<'gctx>

impl<'gctx> !Sync for DirectorySource<'gctx>

impl<'gctx> !Sync for GitSource<'gctx>

impl<'gctx> !Sync for PathSource<'gctx>

impl<'gctx> !Sync for RecursivePathSource<'gctx>

impl<'gctx> !Sync for Download<'gctx>

impl<'gctx> !Sync for Downloads<'gctx>

impl<'gctx> !Sync for HttpRegistry<'gctx>

impl<'gctx> !Sync for CacheManager<'gctx>

impl<'gctx> !Sync for RegistryIndex<'gctx>

impl<'gctx> !Sync for LocalRegistry<'gctx>

impl<'gctx> !Sync for RemoteRegistry<'gctx>

impl<'gctx> !Sync for RegistrySource<'gctx>

impl<'gctx> !Sync for ReplacedSource<'gctx>

impl<'gctx> !Sync for ConfigMapAccess<'gctx>

impl<'gctx> !Sync for Deserializer<'gctx>

impl<'gctx> !Sync for ValueDeserializer<'gctx>

impl<'gctx> !Sync for Progress<'gctx>

impl<'gctx> !Sync for State<'gctx>

impl<'lock> !Sync for CacheLock<'lock>

impl<'s> Sync for Source<'s>

impl<'src> !Sync for SourceMap<'src>

impl<D> Sync for Hyperlink<D>
where D: Sync,

impl<N, E> !Sync for Graph<N, E>

impl<N, E, V> Sync for DependencyQueue<N, E, V>
where N: Sync, V: Sync, E: Sync,

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

impl<T> !Sync for RcVecIter<T>

impl<T> !Sync for LocalDependencies<T>

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

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

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

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

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

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

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

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

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

impl<const N: usize> Sync for MetricsCounter<N>

impl Sync for Error

impl Sync for Stdio

impl<'a> Sync for Action<'a>

impl<'a> Sync for Operation<'a>

impl<'a> Sync for CredentialRequest<'a>

impl<'a> Sync for LoginOptions<'a>

impl<'a> Sync for RegistryInfo<'a>

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

impl Sync for Verbosity

impl Sync for Opts

impl Sync for Target

impl Sync for Cfg

impl Sync for CfgExpr

impl Sync for Platform

impl Sync for ParseError

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

impl<'a> Sync for Parser<'a>

impl<'a> Sync for Tokenizer<'a>

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

impl !Sync for RepoBuilder

impl !Sync for Repository

impl !Sync for HttpServer

impl Sync for EntryData

impl Sync for Token

impl Sync for InMemoryDir

impl Sync for Container

impl Sync for MkFile

impl Sync for TestIdGuard

impl Sync for Dependency

impl Sync for Package

impl Sync for PackageFile

impl Sync for Request

impl Sync for Response

impl Sync for Execs

impl Sync for FileBuilder

impl Sync for Project

impl Sync for RawOutput

impl Sync for RustcInfo

impl<'a> Sync for WildStr<'a>

impl<'a> Sync for Mutation<'a>

impl Sync for Sha256

impl<'a> Sync for PathAncestors<'a>

impl Sync for ErrorKind

impl Sync for ErrorKind

impl Sync for SourceKind

impl Sync for TomlLint

impl Sync for ErrorKind

impl Sync for RustVersion

impl Sync for PathValue

impl Sync for StringOrVec

impl Sync for TomlPackage

impl Sync for TomlProfile

impl Sync for TomlTarget

impl<'a> Sync for PrettyRef<'a>

impl<P> Sync for TomlDependency<P>
where P: Sync,

impl<P> Sync for TomlDetailedDependency<P>
where P: Sync,

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

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

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

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

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

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

impl Sync for Field

impl Sync for Conf

impl Sync for ConfError

impl Sync for FieldError

impl Sync for Suggestion

impl Sync for TryConf

impl Sync for Msrv

impl Sync for Rename

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

impl !Sync for SourceText

impl Sync for Pat

impl Sync for Rel

impl Sync for FullInt

impl Sync for CaptureKind

impl Sync for VecInitKind

impl Sync for PathCheck

impl Sync for Radix

impl Sync for EnumValue

impl Sync for Certainty

impl Sync for Descend

impl Sync for IdentIter

impl Sync for LimitStack

impl Sync for MacroCall

impl Sync for LocalUsage

impl Sync for StrCount

impl Sync for StrIndex

impl<'a> Sync for VecArgs<'a>

impl<'a> Sync for PanicExpn<'a>

impl<'a> Sync for Sugg<'a>

impl<'a> Sync for Range<'a>

impl<'a> Sync for V<'a>

impl<'a> Sync for NumericLiteral<'a>

impl<'a, 'b, 'tcx> !Sync for HirEqInterExpr<'a, 'b, 'tcx>

impl<'a, 'b, 'tcx> !Sync for PossibleBorrowerVisitor<'a, 'b, 'tcx>

impl<'a, 'tcx> !Sync for SpanlessEq<'a, 'tcx>

impl<'a, 'tcx> !Sync for SpanlessHash<'a, 'tcx>

impl<'a, 'tcx> !Sync for ContainsName<'a, 'tcx>

impl<'a, 'tcx> !Sync for DerefDelegate<'a, 'tcx>

impl<'a, 'tcx> !Sync for BindingUsageFinder<'a, 'tcx>

impl<'a, 'tcx> Sync for PossibleOriginVisitor<'a, 'tcx>

impl<'b, 'tcx> Sync for PossibleBorrowerMap<'b, 'tcx>

impl<'cx, 'tcx> !Sync for CertaintyVisitor<'cx, 'tcx>

impl<'hir> Sync for IfLetOrMatch<'hir>

impl<'hir> Sync for If<'hir>

impl<'hir> Sync for IfLet<'hir>

impl<'hir> Sync for IfOrIfLet<'hir>

impl<'hir> Sync for While<'hir>

impl<'hir> Sync for WhileLet<'hir>

impl<'tcx> !Sync for ConstEvalCtxt<'tcx>

impl<'tcx> !Sync for ExprUseCtxt<'tcx>

impl<'tcx> Sync for Constant<'tcx>

impl<'tcx> Sync for DefinedTy<'tcx>

impl<'tcx> Sync for ExprUseNode<'tcx>

impl<'tcx> Sync for ExprFnSig<'tcx>

impl<'tcx> Sync for ForLoop<'tcx>

impl<'tcx> Sync for InteriorMut<'tcx>

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

impl Sync for CompareMode

impl Sync for Debugger

impl Sync for Endian

impl Sync for FailMode

impl Sync for Mode

impl Sync for PassMode

impl Sync for Sanitizer

impl Sync for DiffLine

impl Sync for ErrorKind

impl Sync for WhichLine

impl Sync for ProcOutput

impl Sync for Truncated

impl Sync for AllowUnused

impl Sync for AuxType

impl Sync for Emit

impl Sync for LinkToAux

impl Sync for ReadFrom

impl Sync for TestOutput

impl Sync for WillExecute

impl Sync for Config

impl Sync for TargetCfg

impl Sync for TargetCfgs

impl Sync for TestPaths

impl Sync for Mismatch

impl Sync for Error

impl Sync for AuxProps

impl Sync for Need

impl Sync for EarlyProps

impl Sync for TestProps

impl Sync for Diagnostic

impl Sync for ProcArgs

impl Sync for ProcRes

impl Sync for Stamp

impl<'a> Sync for ParsedNameDirective<'a>

impl<'a, A, B> Sync for ContainsEither<'a, A, B>
where A: Sync, B: Sync,

impl<'ln> Sync for CheckDirectiveResult<'ln>

impl<'ln> Sync for DirectiveLine<'ln>

impl<'test> Sync for TestCx<'test>

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

impl !Sync for Registry

impl Sync for Auth

impl Sync for Error

impl Sync for ApiError

impl Sync for Crate

impl Sync for Crates

impl Sync for NewCrate

impl Sync for R

impl Sync for TotalCrates

impl Sync for User

impl Sync for Users

impl Sync for Warnings

impl<'a> Sync for OwnersReq<'a>

impl Sync for Config

impl Sync for NullOptions

impl Sync for Format

impl Sync for Font

impl Sync for MdFormatter

impl Sync for Table

impl Sync for lower

impl<'a> Sync for ManLinkHelper<'a>

impl<'a> Sync for OptionHelper<'a>

impl<'a> Sync for OptionsHelper<'a>

impl<'e> !Sync for ManRenderer<'e>

impl<'e> !Sync for TextRenderer<'e>

impl !Sync for AllocState

impl !Sync for ClockKind

impl !Sync for CArg

impl !Sync for Clock

impl !Sync for FrameState

impl !Sync for GlobalState

impl !Sync for VClockAlloc

impl !Sync for FutexRef

impl !Sync for StoreBuffer

impl !Sync for StoreElement

impl !Sync for FdTable

impl !Sync for Epoll

impl !Sync for ReadyList

impl !Sync for Event

impl !Sync for LinuxFutex

impl !Sync for AnonSocket

impl !Sync for WindowsFutex

impl Sync for RetagFields

impl Sync for Operation

impl Sync for RetagCause

impl Sync for Permission

impl Sync for AccessCause

impl Sync for InstantKind

impl Sync for AccessType

impl Sync for AtomicRwOrd

impl Sync for NaReadType

impl Sync for NaWriteType

impl Sync for AccessType

impl Sync for BlockReason

impl Sync for Timeout

impl Sync for LoadRecency

impl Sync for DiagLevel

impl Sync for IsolatedOp

impl Sync for AccessKind

impl Sync for AtomicOp

impl Sync for MinMax

impl Sync for Provenance

impl Sync for IoError

impl Sync for FlockOp

impl Sync for ClockId

impl Sync for MutexKind

impl Sync for Handle

impl Sync for FloatBinOp

impl Sync for ShiftOp

impl Sync for ReusePool

impl Sync for AccessOp

impl Sync for Creation

impl Sync for DeallocOp

impl Sync for Protection

impl Sync for RetagInfo

impl Sync for RetagOp

impl Sync for TagHistory

impl Sync for Item

impl Sync for Stack

impl Sync for StackCache

impl Sync for Stacks

impl Sync for BorTag

impl Sync for FrameState

impl Sync for DisplayFmt

impl Sync for DisplayRepr

impl Sync for Event

impl Sync for History

impl Sync for HistoryData

impl Sync for Permission

impl Sync for Node

impl Sync for Tree

impl Sync for UniIndex

impl Sync for Instant

impl Sync for DataRace

impl Sync for LocalClocks

impl Sync for InitOnce

impl Sync for InitOnceId

impl Sync for Condvar

impl Sync for CondvarId

impl Sync for Futex

impl Sync for FutexWaiter

impl Sync for Mutex

impl Sync for MutexId

impl Sync for RwLock

impl Sync for RwLockId

impl Sync for ThreadId

impl Sync for VClock

impl Sync for VTimestamp

impl Sync for VectorIdx

impl Sync for LoadInfo

impl Sync for RacingOp

impl Sync for MiriConfig

impl Sync for DynSym

impl Sync for FdId

impl Sync for NullOutput

impl Sync for DirTable

impl Sync for FileHandle

impl Sync for OpenDir

impl Sync for Buffer

impl<'a, 'tcx> !Sync for LiveAllocs<'a, 'tcx>

impl<'a, V> Sync for UniEntry<'a, V>
where V: Sync,

impl<'ecx, 'tcx> !Sync for DiagnosticCxBuilder<'ecx, 'tcx>

impl<'history, 'ecx, 'tcx> !Sync for DiagnosticCx<'history, 'ecx, 'tcx>

impl<'node> Sync for TbError<'node>

impl<'node> Sync for NodeAppArgs<'node>

impl<'node, InErr> Sync for ErrHandlerArgs<'node, InErr>
where InErr: Sync,

impl<'tcx> !Sync for ThreadState<'tcx>

impl<'tcx> !Sync for Thread<'tcx>

impl<'tcx> !Sync for ThreadManager<'tcx>

impl<'tcx> !Sync for AllocExtra<'tcx>

impl<'tcx> !Sync for FrameExtra<'tcx>

impl<'tcx> !Sync for MiriMachine<'tcx>

impl<'tcx> Sync for MainThreadState<'tcx>

impl<'tcx> Sync for EnvVars<'tcx>

impl<'tcx> Sync for TlsDtorsStatePriv<'tcx>

impl<'tcx> Sync for PrimitiveLayouts<'tcx>

impl<'tcx> Sync for CatchUnwindData<'tcx>

impl<'tcx> Sync for TlsData<'tcx>

impl<'tcx> Sync for TlsDtorsState<'tcx>

impl<'tcx> Sync for TlsEntry<'tcx>

impl<'tcx> Sync for UnixEnvVars<'tcx>

impl<'tree> Sync for TreeVisitor<'tree>

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

impl<K, V> !Sync for MonoHashMap<K, V>

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

impl<NodeContinue, NodeApp, ErrHandler> Sync for TreeVisitorStack<NodeContinue, NodeApp, ErrHandler>
where NodeContinue: Sync, NodeApp: Sync, ErrHandler: Sync,

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

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

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

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

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

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

impl Sync for Command

impl Sync for Diff

impl Sync for Cc

impl Sync for Clang

impl Sync for LlvmAr

impl Sync for LlvmDis

impl Sync for LlvmNm

impl Sync for LlvmObjcopy

impl Sync for LlvmObjdump

impl Sync for LlvmPdbutil

impl Sync for LlvmReadobj

impl Sync for Rustc

impl Sync for Rustdoc

impl Sync for RegKind

impl Sync for BackendRepr

impl Sync for Endian

impl Sync for Float

impl Sync for Integer

impl Sync for IntegerType

impl Sync for PointerKind

impl Sync for Primitive

impl Sync for Scalar

impl Sync for StructKind

impl Sync for AbiDisabled

impl Sync for ExternAbi

impl Sync for NicheBias

impl Sync for Reg

impl Sync for AbiData

impl Sync for FieldIdx

impl Sync for VariantIdx

impl Sync for Align

impl Sync for Niche

impl Sync for PointeeInfo

impl Sync for ReprFlags

impl Sync for ReprOptions

impl Sync for Size

impl<'a> Sync for TargetDataLayoutErrors<'a>

impl<'a> Sync for Layout<'a>

impl<'a, Ty> Sync for TyAndLayout<'a, Ty>
where Ty: Sync,

impl<Cx> Sync for LayoutCalculator<Cx>
where Cx: Sync,

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

impl<FieldIdx> Sync for FieldsShape<FieldIdx>

impl<FieldIdx, VariantIdx> Sync for Variants<FieldIdx, VariantIdx>
where VariantIdx: Sync,

impl<FieldIdx, VariantIdx> Sync for LayoutData<FieldIdx, VariantIdx>
where VariantIdx: Sync,

impl<VariantIdx> Sync for TagEncoding<VariantIdx>
where VariantIdx: Sync,

impl Sync for IsCopy

impl Sync for IsNotCopy

impl<T = u8> !Sync for ArenaChunk<T>

impl<T> !Sync for TypedArena<T>

impl !Sync for AttrArgs

impl !Sync for AttrArgsEq

impl !Sync for AttrKind

impl !Sync for ExprKind

impl !Sync for FnRetTy

impl !Sync for GenericArg

impl !Sync for GenericArgs

impl !Sync for GenericBound

impl !Sync for ItemKind

impl !Sync for LocalKind

impl !Sync for MetaItemKind

impl !Sync for ModKind

impl !Sync for PatKind

impl !Sync for SelfKind

impl !Sync for StmtKind

impl !Sync for StructRest

impl !Sync for Term

impl !Sync for TyKind

impl !Sync for UseTreeKind

impl !Sync for VariantData

impl !Sync for Nonterminal

impl !Sync for TokenKind

impl !Sync for TokenTree

impl !Sync for AnonConst

impl !Sync for Arm

impl !Sync for AttrItem

impl !Sync for Attribute

impl !Sync for BareFnTy

impl !Sync for Block

impl !Sync for Closure

impl !Sync for ConstItem

impl !Sync for Crate

impl !Sync for Delegation

impl !Sync for DelimArgs

impl !Sync for EnumDef

impl !Sync for Expr

impl !Sync for ExprField

impl !Sync for FieldDef

impl !Sync for Fn

impl !Sync for FnDecl

impl !Sync for FnSig

impl !Sync for ForeignMod

impl !Sync for GenericParam

impl !Sync for Generics

impl !Sync for Impl

impl !Sync for InlineAsm

impl !Sync for InlineAsmSym

impl !Sync for Local

impl !Sync for MacCall

impl !Sync for MacCallStmt

impl !Sync for MacroDef

impl !Sync for MetaItem

impl !Sync for MethodCall

impl !Sync for MutTy

impl !Sync for NormalAttr

impl !Sync for Param

impl !Sync for Pat

impl !Sync for PatField

impl !Sync for Path

impl !Sync for PathSegment

impl !Sync for PolyTraitRef

impl !Sync for QSelf

impl !Sync for StaticItem

impl !Sync for Stmt

impl !Sync for StructExpr

impl !Sync for Trait

impl !Sync for TraitRef

impl !Sync for Ty

impl !Sync for TyAlias

impl !Sync for UseTree

impl !Sync for Variant

impl !Sync for Visibility

impl !Sync for WhereClause

impl !Sync for FormatArgs

impl !Sync for Token

impl !Sync for AttrsTarget

impl !Sync for TokenStream

impl Sync for AsmMacro

impl Sync for AttrStyle

impl Sync for BinOpKind

impl Sync for BorrowKind

impl Sync for ByRef

impl Sync for CaptureBy

impl Sync for Const

impl Sync for Defaultness

impl Sync for Extern

impl Sync for FloatTy

impl Sync for ForLoopKind

impl Sync for Inline

impl Sync for IntTy

impl Sync for IsAuto

impl Sync for LitIntType

impl Sync for LitKind

impl Sync for MatchKind

impl Sync for RangeEnd

impl Sync for RangeLimits

impl Sync for RangeSyntax

impl Sync for Recovered

impl Sync for Safety

impl Sync for StrStyle

impl Sync for UintTy

impl Sync for UnOp

impl Sync for AllocatorTy

impl Sync for DiffMode

impl Sync for Kind

impl Sync for FormatCount

impl Sync for FormatSign

impl Sync for FormatTrait

impl Sync for BinOpToken

impl Sync for CommentKind

impl Sync for Delimiter

impl Sync for IdentIsRaw

impl Sync for LitKind

impl Sync for NtExprKind

impl Sync for NtPatKind

impl Sync for Spacing

impl Sync for Case

impl Sync for LitError

impl Sync for AssocOp

impl Sync for Fixity

impl Sync for AssocCtxt

impl Sync for BoundKind

impl Sync for FnCtxt

impl Sync for BindingMode

impl Sync for FnHeader

impl Sync for Label

impl Sync for Lifetime

impl Sync for MetaItemLit

impl Sync for ModSpans

impl Sync for StrLit

impl Sync for MarkedAttrs

impl Sync for FncTree

impl Sync for Type

impl Sync for TypeTree

impl Sync for NodeId

impl Sync for Lit

impl Sync for DelimSpan

impl Sync for Comment

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

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

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

impl<'t> !Sync for RefTokenTreeCursor<'t>

impl<K = ItemKind> !Sync for Item<K>

impl<ModId = DefId> !Sync for StrippedCfgItem<ModId>

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

impl<Wrapped, Tag> Sync for AstNodeWrapper<Wrapped, Tag>
where Wrapped: Sync, Tag: Sync,

impl Sync for Movability

impl Sync for Mutability

impl Sync for Pinnedness

impl Sync for FnDeclKind

impl Sync for ParamMode

impl Sync for FutureKind

impl Sync for InvalidAbi

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

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

impl<'a> Sync for SelfResolver<'a>

impl<'a> Sync for ExtraDoubleDot<'a>

impl<'a> Sync for InvalidRegister<'a>

impl<'a> Sync for InvalidRegisterClass<'a>

impl<'a> Sync for RegisterConflict<'a>

impl<'a> Sync for SubTupleBinding<'a>

impl<'a, 'hir> !Sync for NodeCollector<'a, 'hir>

impl<'a, 'hir> !Sync for ItemLowerer<'a, 'hir>

impl<'a, 'hir> !Sync for LoweringContext<'a, 'hir>

impl<'hir> Sync for DelegationResults<'hir>

impl<'hir> Sync for GenericArgsCtor<'hir>

impl Sync for Mode

impl Sync for ShowSpan

impl Sync for UnsafeItem

impl Sync for NodeCounter

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

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

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

impl<'a> Sync for BodyInExtern<'a>

impl<'a> Sync for BoundInContext<'a>

impl<'a> Sync for ExternTypesCannotHave<'a>

impl<'a> Sync for InherentImplCannot<'a>

impl<'a> Sync for ItemUnderscore<'a>

impl<'a> Sync for OutOfOrderParams<'a>

impl Sync for Breaks

impl Sync for IndentStyle

impl Sync for PrintFrame

impl Sync for Token

impl Sync for BeginToken

impl Sync for BreakToken

impl Sync for BufEntry

impl Sync for Printer

impl Sync for NoAnn

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

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

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

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

impl<'a> Sync for DelegationKind<'a>

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

impl Sync for InlineAttr

impl Sync for IntType

impl Sync for ReprAttr

impl Sync for StableSince

impl Sync for Condition

impl Sync for Deprecation

impl Sync for Stability

impl Sync for MissingNote

impl Sync for SoftNoArgs

impl<'a> Sync for InvalidReprGeneric<'a>

impl<'a> Sync for UnknownMetaItem<'a>

impl Sync for DefUse

impl Sync for AccessKind

impl Sync for AccessDepth

impl Sync for Overlap

impl Sync for ReadKind

impl Sync for ReadOrWrite

impl Sync for WriteKind

impl Sync for Control

impl Sync for PrefixSet

impl Sync for Cause

impl Sync for RegionCtxt

impl Sync for Locations

impl Sync for Normal

impl Sync for Reverse

impl Sync for BorrowIndex

impl Sync for BreakFinder

impl Sync for MoveSite

impl Sync for RegionName

impl Sync for RustcFacts

impl Sync for LiveLoans

impl Sync for FnMutError

impl Sync for Appearance

impl Sync for LocalUseMap

impl<'a> Sync for CaptureReasonLabel<'a>

impl<'a> Sync for OnClosureNote<'a>

impl<'a> Sync for MoveBorrow<'a>

impl<'a> Sync for AppearancesIter<'a>

impl<'a, 'b, 'infcx, 'tcx> !Sync for GatherUsedMutsVisitor<'a, 'b, 'infcx, 'tcx>

impl<'a, 'b, 'tcx> !Sync for NllTypeRelating<'a, 'b, 'tcx>

impl<'a, 'b, 'tcx> !Sync for TypeVerifier<'a, 'b, 'tcx>

impl<'a, 'infcx, 'tcx> !Sync for MirBorrowckCtxt<'a, 'infcx, 'tcx>

impl<'a, 'tcx> !Sync for GatherBorrows<'a, 'tcx>

impl<'a, 'tcx> !Sync for BorrowckDomain<'a, 'tcx>

impl<'a, 'tcx> !Sync for BorrowckResults<'a, 'tcx>

impl<'a, 'tcx> !Sync for Borrows<'a, 'tcx>

impl<'a, 'tcx> !Sync for OutOfScopePrecomputer<'a, 'tcx>

impl<'a, 'tcx> !Sync for PoloniusOutOfScopePrecomputer<'a, 'tcx>

impl<'a, 'tcx> !Sync for DefUseVisitor<'a, 'tcx>

impl<'a, 'tcx> !Sync for UseFinder<'a, 'tcx>

impl<'a, 'tcx> !Sync for FindOpaqueRegion<'a, 'tcx>

impl<'a, 'tcx> !Sync for LoanInvalidationsGenerator<'a, 'tcx>

impl<'a, 'tcx> !Sync for LoanKillsGenerator<'a, 'tcx>

impl<'a, 'tcx> !Sync for RawConstraints<'a, 'tcx>

impl<'a, 'tcx> !Sync for SccConstraints<'a, 'tcx>

impl<'a, 'tcx> !Sync for RegionRenumberer<'a, 'tcx>

impl<'a, 'tcx> !Sync for ConstraintConversion<'a, 'tcx>

impl<'a, 'tcx> !Sync for UniversalRegionRelationsBuilder<'a, 'tcx>

impl<'a, 'tcx> !Sync for LiveVariablesVisitor<'a, 'tcx>

impl<'a, 'tcx> !Sync for TypeChecker<'a, 'tcx>

impl<'a, 'tcx> Sync for TypeNoCopy<'a, 'tcx>

impl<'a, 'tcx> Sync for NonGenericOpaqueTypeParam<'a, 'tcx>

impl<'a, 'tcx> Sync for UseFactsExtractor<'a, 'tcx>

impl<'a, 'tcx, D> Sync for Edges<'a, 'tcx, D>
where D: Sync,

impl<'a, 'tcx, D> Sync for RegionGraph<'a, 'tcx, D>
where D: Sync,

impl<'a, 'tcx, D> Sync for Successors<'a, 'tcx, D>
where D: Sync,

impl<'a, 'typeck, 'b, 'tcx> !Sync for LivenessContext<'a, 'typeck, 'b, 'tcx>

impl<'a, 'typeck, 'b, 'tcx> !Sync for LivenessResults<'a, 'typeck, 'b, 'tcx>

impl<'infcx> !Sync for BufferedDiag<'infcx>

impl<'infcx, 'tcx> !Sync for BorrowckDiags<'infcx, 'tcx>

impl<'infcx, 'tcx> !Sync for UniversalRegionsBuilder<'infcx, 'tcx>

impl<'me> Sync for LocalUseMapBuild<'me>

impl<'tcx> !Sync for UniverseInfo<'tcx>

impl<'tcx> !Sync for BodyWithBorrowckFacts<'tcx>

impl<'tcx> !Sync for ConditionVisitor<'tcx>

impl<'tcx> !Sync for RegionErrors<'tcx>

impl<'tcx> !Sync for NllOutput<'tcx>

impl<'tcx> !Sync for LazyOpaqueTyEnv<'tcx>

impl<'tcx> !Sync for RegionInferenceContext<'tcx>

impl<'tcx> !Sync for BorrowckInferCtxt<'tcx>

impl<'tcx> !Sync for CreateResult<'tcx>

impl<'tcx> !Sync for UniversalRegionRelations<'tcx>

impl<'tcx> !Sync for MirTypeckRegionConstraints<'tcx>

impl<'tcx> !Sync for MirTypeckResults<'tcx>

impl<'tcx> !Sync for UniversalRegionIndices<'tcx>

impl<'tcx> !Sync for UniversalRegions<'tcx>

impl<'tcx> Sync for AnnotatedBorrowFnSignature<'tcx>

impl<'tcx> Sync for StorageDeadOrDrop<'tcx>

impl<'tcx> Sync for BorrowedContentSource<'tcx>

impl<'tcx> Sync for UseSpans<'tcx>

impl<'tcx> Sync for BorrowExplanation<'tcx>

impl<'tcx> Sync for GroupedMoveError<'tcx>

impl<'tcx> Sync for IllegalMoveOriginKind<'tcx>

impl<'tcx> Sync for RegionErrorKind<'tcx>

impl<'tcx> Sync for Trace<'tcx>

impl<'tcx> Sync for CaptureReasonSuggest<'tcx>

impl<'tcx> Sync for DefiningTy<'tcx>

impl<'tcx> Sync for BorrowData<'tcx>

impl<'tcx> Sync for BorrowSet<'tcx>

impl<'tcx> Sync for OutlivesConstraint<'tcx>

impl<'tcx> Sync for OutlivesConstraintSet<'tcx>

impl<'tcx> Sync for AscribeUserTypeQuery<'tcx>

impl<'tcx> Sync for PredicateQuery<'tcx>

impl<'tcx> Sync for MoveError<'tcx>

impl<'tcx> Sync for ErrorConstraintInfo<'tcx>

impl<'tcx> Sync for NllMemberConstraint<'tcx>

impl<'tcx> Sync for Prefixes<'tcx>

impl<'tcx> Sync for BlameConstraint<'tcx>

impl<'tcx> Sync for RegionDefinition<'tcx>

impl<'tcx> Sync for TypeTest<'tcx>

impl<'tcx> Sync for LifetimeMismatchOpaqueParam<'tcx>

impl<'tcx> Sync for MoveUnsized<'tcx>

impl<'tcx> Sync for RootPlace<'tcx>

impl<'tcx> Sync for TyCtxtConsts<'tcx>

impl<'tcx> Sync for DropData<'tcx>

impl<'tcx> Sync for InstantiateOpaqueType<'tcx>

impl<'tcx, R> Sync for MemberConstraintSet<'tcx, R>
where R: Sync,

impl<'tcx, T> Sync for NormalizeQuery<'tcx, T>
where T: Sync,

impl<'w> Sync for FactWriter<'w>

impl<D> Sync for ConstraintGraph<D>
where D: Sync,

impl<N> !Sync for RegionValues<N>

impl !Sync for AsmArgs

impl !Sync for Capture

impl !Sync for Assert

impl !Sync for BlockOrExpr

impl !Sync for FieldInfo

impl !Sync for MacroInput

impl Sync for IsTuple

impl Sync for PathKind

impl Sync for Ty

impl Sync for Num

impl Sync for State

impl Sync for ProcMacro

impl Sync for ShouldPanic

impl Sync for TestType

impl Sync for Expander

impl Sync for Expander

impl Sync for Bounds

impl Sync for Path

impl Sync for AsmNoReturn

impl Sync for BenchSig

impl Sync for DeriveUnion

impl Sync for NonABI

impl Sync for ProcMacro

impl Sync for TestBadFn

impl Sync for TraceMacros

impl Sync for Test

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

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

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

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

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

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

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

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

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

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

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

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

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

impl<'a> Sync for Substitution<'a>

impl<'a> Sync for Substitution<'a>

impl<'a> Sync for AsmUnsupportedOperand<'a>

impl<'a> Sync for ExpectedItem<'a>

impl<'a> Sync for FormatUnknownTrait<'a>

impl<'a> Sync for OnlyOneArgument<'a>

impl<'a> Sync for TakesNoArguments<'a>

impl<'a> Sync for Format<'a>

impl<'a> Sync for Substitutions<'a>

impl<'a> Sync for Substitutions<'a>

impl<'a> Sync for StrCursor<'a>

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

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

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

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

impl<'cx, 'a> !Sync for Context<'cx, 'a>

impl !Sync for Addition

impl !Sync for DebugLoc

impl !Sync for ArchiveRO

impl Sync for CounterKind

impl Sync for ExprKind

impl Sync for DiscrResult

impl Sync for WidePtrKind

impl Sync for ArchiveKind

impl Sync for AsmDialect

impl Sync for CallConv

impl Sync for CodeModel

impl Sync for FileType

impl Sync for Linkage

impl Sync for OptStage

impl Sync for RelocModel

impl Sync for TypeKind

impl Sync for UnnamedAddr

impl Sync for Visibility

impl Sync for CodeRegion

impl Sync for Counter

impl Sync for LocalFileId

impl Sync for Split128

impl Sync for HiddenZst

impl Sync for CopyBitcode

impl Sync for LtoDylib

impl Sync for DIFlags

impl Sync for DISPFlags

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

impl<'a> Sync for LlvmError<'a>

impl<'a> Sync for PossibleFeature<'a>

impl<'a> Sync for LlvmSelfProfiler<'a>

impl<'a> Sync for FixedX18InvalidArch<'a>

impl<'a> Sync for ForbiddenCTargetFeature<'a>

impl<'a> Sync for MismatchedDataLayout<'a>

impl<'a> Sync for SymbolAlreadyDefined<'a>

impl<'a> Sync for UnknownCTargetFeature<'a>

impl<'a> Sync for UnstableCTargetFeature<'a>

impl<'a> Sync for WithLlvmError<'a>

impl<'a> Sync for WriteBytecode<'a>

impl<'a> Sync for LLVMFeature<'a>

impl<'a, 'll> !Sync for VariantMemberInfo<'a, 'll>

impl<'a, 'll, 'tcx> !Sync for Builder<'a, 'll, 'tcx>

impl<'ll> !Sync for Stub<'ll>

impl<'ll> !Sync for Diagnostic<'ll>

impl<'ll> !Sync for ValueIter<'ll>

impl<'ll> !Sync for Funclet<'ll>

impl<'ll> !Sync for VariantFieldInfo<'ll>

impl<'ll> !Sync for DINodeCreationResult<'ll>

impl<'ll> !Sync for OptimizationDiagnostic<'ll>

impl<'ll, 'tcx> !Sync for CodegenCx<'ll, 'tcx>

impl<'ll, 'tcx> !Sync for CrateCoverageContext<'ll, 'tcx>

impl<'ll, 'tcx> !Sync for StubInfo<'ll, 'tcx>

impl<'ll, 'tcx> !Sync for TypeMap<'ll, 'tcx>

impl<'ll, 'tcx> !Sync for CodegenUnitDebugContext<'ll, 'tcx>

impl<'tcx> Sync for UniqueTypeId<'tcx>

impl<'tcx> Sync for FunctionCoverage<'tcx>

impl<'tcx> Sync for FunctionCoverageCollector<'tcx>

impl<'tcx> Sync for UsageSets<'tcx>

impl<T> Sync for RawEnum<T>

impl !Sync for CrateInfo

impl !Sync for NativeLib

impl Sync for CguReuse

impl Sync for Program

impl Sync for RlibFlavor

impl Sync for EmitObj

impl Sync for TypeKind

impl Sync for ModuleKind

impl Sync for CleanupKind

impl Sync for LocalKind

impl Sync for MergingSucc

impl Sync for OverflowOp

impl Sync for TrackerData

impl Sync for Command

impl Sync for CguMessage

impl Sync for Diagnostic

impl Sync for CopyPathBuf

impl Sync for NoField

impl Sync for MemFlags

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

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

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

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

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

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

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

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

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

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

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

impl<'a> Sync for AppleSdkRootError<'a>

impl<'a> Sync for RPathConfig<'a>

impl<'a> Sync for CguNotRecorded<'a>

impl<'a> Sync for CopyPath<'a>

impl<'a> Sync for DebugArgPath<'a>

impl<'a> Sync for ErrorCallingDllTool<'a>

impl<'a> Sync for IncorrectCguReuseType<'a>

impl<'a> Sync for LinkingFailed<'a>

impl<'a> Sync for NoModuleNamed<'a>

impl<'a> Sync for NoSavedObjectFile<'a>

impl<'a> Sync for UnableToRun<'a>

impl<'a> Sync for UnknownArchiveKind<'a>

impl<'a> Sync for UnsupportedArch<'a>

impl<'a, 'b, 'tcx, Bx> Sync for LocalAnalyzer<'a, 'b, 'tcx, Bx>

impl<'a, 'tcx, Bx> Sync for ConstDebugInfo<'a, 'tcx, Bx>

impl<'a, 'tcx, Bx> Sync for FunctionCx<'a, 'tcx, Bx>

impl<'tcx> !Sync for AssertModuleSource<'tcx>

impl<'tcx> Sync for InvalidMonomorphization<'tcx>

impl<'tcx> Sync for GlobalAsmOperandRef<'tcx>

impl<'tcx> Sync for FailedToGetLayout<'tcx>

impl<'tcx> Sync for TerminatorCodegenHelper<'tcx>

impl<'tcx, B> Sync for InlineAsmOperandRef<'tcx, B>
where <B as BackendTypes>::BasicBlock: Sync, <B as BackendTypes>::Value: Sync, B: ?Sized,

impl<'tcx, D> Sync for PerLocalVarDebugInfo<'tcx, D>
where D: Sync,

impl<'tcx, S, L> Sync for FunctionDebugContext<'tcx, S, L>
where S: Sync, L: Sync,

impl<'tcx, V> Sync for ReturnDest<'tcx, V>
where V: Sync,

impl<'tcx, V> Sync for LocalRef<'tcx, V>
where V: Sync,

impl<'tcx, V> Sync for Locals<'tcx, V>
where V: Sync,

impl<'tcx, V> Sync for OperandRef<'tcx, V>
where V: Sync,

impl<'tcx, V> Sync for PlaceRef<'tcx, V>
where V: Sync,

impl<B> !Sync for OngoingCodegen<B>

impl<B> Sync for LtoModuleCodegen<B>

impl<B> Sync for FatLtoInput<B>

impl<B> Sync for Message<B>

impl<B> Sync for WorkItem<B>

impl<B> Sync for WorkItemResult<B>

impl<B> Sync for ThinModule<B>

impl<B> Sync for ThinShared<B>

impl<B> Sync for CodegenContext<B>

impl<B> Sync for Coordinator<B>

impl<M> Sync for SerializedModule<M>

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

impl<S, L> Sync for DebugScope<S, L>
where S: Sync, L: Sync,

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

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

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

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

impl !Sync for SpanGuard

impl Sync for Status

impl Sync for MemoryKind

impl Sync for InternKind

impl Sync for AllocKind

impl Sync for OffsetMode

impl Sync for PathElem

impl Sync for Coroutine

impl Sync for InlineAsm

impl Sync for PanicNonStr

impl Sync for NeedsDrop

impl Sync for State

impl Sync for FrameNote

impl Sync for LongRunning

impl Sync for AllocInfo

impl Sync for RangeSet

impl<'a, 'mir, 'tcx, Q> !Sync for FlowSensitiveAnalysis<'a, 'mir, 'tcx, Q>

impl<'a, 'mir, 'tcx, Q> !Sync for TransferFunction<'a, 'mir, 'tcx, Q>

impl<'a, 'tcx, Prov, Extra, Bytes = Box<[u8]>> !Sync for AllocRef<'a, 'tcx, Prov, Extra, Bytes>

impl<'a, 'tcx, Prov, Extra, Bytes = Box<[u8]>> !Sync for AllocRefMut<'a, 'tcx, Prov, Extra, Bytes>

impl<'a, 'tcx, Prov, P> Sync for ArrayIterator<'a, 'tcx, Prov, P>
where P: Sync, Prov: Sync,

impl<'mir, 'tcx> !Sync for Checker<'mir, 'tcx>

impl<'mir, 'tcx> !Sync for Qualifs<'mir, 'tcx>

impl<'mir, 'tcx> !Sync for CheckLiveDrops<'mir, 'tcx>

impl<'mir, 'tcx> !Sync for ConstCx<'mir, 'tcx>

impl<'rt, 'tcx, M> !Sync for ValidityVisitor<'rt, 'tcx, M>

impl<'tcx> !Sync for CompileTimeMachine<'tcx>

impl<'tcx> !Sync for AbsolutePathPrinter<'tcx>

impl<'tcx> Sync for ValTreeCreationError<'tcx>

impl<'tcx> Sync for ConditionallyConstCall<'tcx>

impl<'tcx> Sync for FnCallNonConst<'tcx>

impl<'tcx> Sync for LiveDrop<'tcx>

impl<'tcx> Sync for LiveDrop<'tcx>

impl<'tcx> Sync for NonConstAwait<'tcx>

impl<'tcx> Sync for NonConstDerefCoercion<'tcx>

impl<'tcx> Sync for NonConstForLoopIntoIter<'tcx>

impl<'tcx> Sync for NonConstMatchEq<'tcx>

impl<'tcx> Sync for NonConstQuestionBranch<'tcx>

impl<'tcx> Sync for NonConstQuestionFromResidual<'tcx>

impl<'tcx> Sync for NonConstTryBlockFromOutput<'tcx>

impl<'tcx> Sync for FrameInfo<'tcx>

impl<'tcx, M> !Sync for InterpCx<'tcx, M>

impl<'tcx, M> Sync for Memory<'tcx, M>
where <M as Machine<'tcx>>::MemoryMap: Sync, <M as Machine<'tcx>>::ExtraFnVal: Sync,

impl<'tcx, M> Sync for EvaluatedCalleeAndArgs<'tcx, M>
where <M as Machine<'tcx>>::ExtraFnVal: Sync, <M as Machine<'tcx>>::Provenance: Sync,

impl<'tcx, Other> Sync for FnVal<'tcx, Other>
where Other: Sync,

impl<'tcx, Prov = CtfeProvenance> !Sync for LocalState<'tcx, Prov>

impl<'tcx, Prov = CtfeProvenance, Extra = ()> !Sync for Frame<'tcx, Prov, Extra>

impl<'tcx, Prov> Sync for FnArg<'tcx, Prov>
where Prov: Sync,

impl<'tcx, Prov> Sync for ImmTy<'tcx, Prov>
where Prov: Sync,

impl<'tcx, Prov> Sync for OpTy<'tcx, Prov>
where Prov: Sync,

impl<'tcx, Prov> Sync for MPlaceTy<'tcx, Prov>
where Prov: Sync,

impl<'tcx, Prov> Sync for PlaceTy<'tcx, Prov>
where Prov: Sync,

impl<'tcx, Prov> Sync for StackPopInfo<'tcx, Prov>
where Prov: Sync,

impl<Prov> Sync for Immediate<Prov>
where Prov: Sync,

impl<Prov> Sync for Operand<Prov>
where Prov: Sync,

impl<Prov> Sync for MemPlaceMeta<Prov>
where Prov: Sync,

impl<Prov> Sync for Place<Prov>
where Prov: Sync,

impl<Prov> Sync for LocalValue<Prov>
where Prov: Sync,

impl<Prov> Sync for MemPlace<Prov>
where Prov: Sync,

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

impl<T, PATH> Sync for RefTracking<T, PATH>
where T: Sync, PATH: Sync,

impl Sync for Error

impl Sync for Compilation

impl Sync for Expander

impl Sync for AstNoAnn

impl Sync for Ice

impl Sync for IceFlags

impl Sync for IcePath

impl Sync for RawStderr

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

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

impl<'a> Sync for IceBugReport<'a>

impl<'a> Sync for IceVersion<'a>

impl<'a> Sync for RlinkCorruptFile<'a>

impl<'tcx> !Sync for PrintExtra<'tcx>

impl<'tcx> !Sync for HirIdentifiedAnn<'tcx>

impl<'tcx> !Sync for HirTypedAnn<'tcx>

impl Sync for DiagMessage

impl Sync for MultiSpan

impl Sync for SpanLabel

impl !Sync for HumanEmitter

impl !Sync for JsonEmitter

impl !Sync for DiagCtxt

impl Sync for ColorConfig

impl Sync for OutputTheme

impl Sync for Level

impl Sync for StashKey

impl Sync for Suggestions

impl Sync for TerminalUrl

impl Sync for BreakRule

impl Sync for ParseOpt

impl Sync for Prev

impl Sync for Style

impl Sync for ErrCode

impl Sync for BugAbort

impl Sync for DiagInner

impl Sync for FatalAbort

impl Sync for IsLint

impl Sync for StringPart

impl Sync for Subdiag

impl Sync for Buffy

impl Sync for Margin

impl Sync for Diagnostic

impl Sync for Context

impl Sync for Registry

impl Sync for Annotation

impl Sync for Line

impl Sync for ExplicitBug

impl Sync for StyledChar

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

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

impl<'a> Sync for EmitTyped<'a>

impl<'a> Sync for MdTree<'a>

impl<'a> Sync for ArtifactNotification<'a>

impl<'a> Sync for FutureBreakageItem<'a>

impl<'a> Sync for FutureIncompatReport<'a>

impl<'a> Sync for UnusedExterns<'a>

impl<'a> Sync for MdStream<'a>

impl<'a, G = ErrorGuaranteed> !Sync for Diag<'a, G>

impl<'args> !Sync for TranslateError<'args>

impl<'args> Sync for TranslateErrorKind<'args>

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

impl !Sync for Annotatable

impl !Sync for AstFragment

impl !Sync for TokenTree

impl !Sync for MatcherLoc

impl !Sync for NamedMatch

impl !Sync for FrameKind

impl !Sync for MacEager

impl !Sync for Invocation

impl !Sync for BestFailure

impl !Sync for MatcherPos

impl !Sync for TtParser

impl !Sync for Delimited

impl Sync for InvalidCfg

impl Sync for KleeneOp

impl Sync for CanRetry

impl Sync for IsInFollow

impl Sync for MetaVarExpr

impl Sync for DummyResult

impl Sync for ModuleData

impl Sync for OnlyOneWord

impl Sync for TraceMacro

impl Sync for ImplItemTag

impl Sync for OptExprTag

impl Sync for BinderInfo

impl Sync for NoopTracker

impl Sync for KleeneToken

impl Sync for Marker

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

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

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

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

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

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

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

impl<'a> Sync for CannotBeNameOfMacro<'a>

impl<'a> Sync for ExpectedParenOrBrace<'a>

impl<'a> Sync for FeatureRemoved<'a>

impl<'a> Sync for FeatureRemovedReason<'a>

impl<'a> Sync for RecursionLimitReached<'a>

impl<'a> Sync for MacroState<'a>

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

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

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

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

impl<'dcx, 'matcher> !Sync for CollectTrackerAndEmitter<'dcx, 'matcher>

impl<'feat> Sync for ExpansionConfig<'feat>

impl<'matcher> !Sync for FailureForwarder<'matcher>

impl<'tt> !Sync for TtHandle<'tt>

impl<'tt> !Sync for FirstSets<'tt>

impl<'tt> !Sync for TokenSet<'tt>

impl<T> !Sync for MessagePipe<T>

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

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

impl Sync for GateIssue

impl Sync for Stability

impl Sync for Feature

impl Sync for Features

impl Sync for LinkOrCopy

impl Sync for Style

impl<'a> Sync for LabelText<'a>

impl<'a> Sync for Id<'a>

impl Sync for CtorKind

impl Sync for CtorOf

impl Sync for DefKind

impl Sync for LifetimeRes

impl Sync for Namespace

impl Sync for DefPathData

impl Sync for ClosureKind

impl Sync for Constness

impl Sync for Defaultness

impl Sync for IsAsync

impl Sync for LocalSource

impl Sync for LoopIdError

impl Sync for LoopSource

impl Sync for MatchSource

impl Sync for ParamName

impl Sync for PrimTy

impl Sync for RangeEnd

impl Sync for RpitContext

impl Sync for Safety

impl Sync for UseKind

impl Sync for YieldSource

impl Sync for LangItem

impl Sync for MethodKind

impl Sync for Target

impl Sync for PartialRes

impl Sync for Config

impl Sync for DefKey

impl Sync for DefPath

impl Sync for Definitions

impl Sync for AnonConst

impl Sync for BodyId

impl Sync for ConstBlock

impl Sync for Destination

impl Sync for DotDotPos

impl Sync for FnHeader

impl Sync for ImplItemId

impl Sync for ImplItemRef

impl Sync for InferArg

impl Sync for ItemId

impl Sync for Lifetime

impl Sync for ModSpans

impl Sync for TraitItemId

impl Sync for Upvar

impl Sync for HirId

impl Sync for ItemLocalId

impl Sync for OwnerId

impl Sync for None

impl<'a> Sync for FnKind<'a>

impl<'hir> !Sync for ItemKind<'hir>

impl<'hir> !Sync for Node<'hir>

impl<'hir> !Sync for OwnerNode<'hir>

impl<'hir> !Sync for Crate<'hir>

impl<'hir> !Sync for Item<'hir>

impl<'hir> !Sync for OwnerInfo<'hir>

impl<'hir> Sync for ArrayLen<'hir>

impl<'hir> Sync for AssocItemConstraintKind<'hir>

impl<'hir> Sync for ConstArgKind<'hir>

impl<'hir> Sync for ExprKind<'hir>

impl<'hir> Sync for FnRetTy<'hir>

impl<'hir> Sync for ForeignItemKind<'hir>

impl<'hir> Sync for GenericArg<'hir>

impl<'hir> Sync for GenericBound<'hir>

impl<'hir> Sync for GenericParamKind<'hir>

impl<'hir> Sync for ImplItemKind<'hir>

impl<'hir> Sync for InlineAsmOperand<'hir>

impl<'hir> Sync for PatKind<'hir>

impl<'hir> Sync for PreciseCapturingArg<'hir>

impl<'hir> Sync for QPath<'hir>

impl<'hir> Sync for StmtKind<'hir>

impl<'hir> Sync for Term<'hir>

impl<'hir> Sync for TraitFn<'hir>

impl<'hir> Sync for TraitItemKind<'hir>

impl<'hir> Sync for TyKind<'hir>

impl<'hir> Sync for VariantData<'hir>

impl<'hir> Sync for WherePredicate<'hir>

impl<'hir> Sync for Arm<'hir>

impl<'hir> Sync for AssocItemConstraint<'hir>

impl<'hir> Sync for BareFnTy<'hir>

impl<'hir> Sync for Block<'hir>

impl<'hir> Sync for Body<'hir>

impl<'hir> Sync for Closure<'hir>

impl<'hir> Sync for ConstArg<'hir>

impl<'hir> Sync for EnumDef<'hir>

impl<'hir> Sync for Expr<'hir>

impl<'hir> Sync for ExprField<'hir>

impl<'hir> Sync for FieldDef<'hir>

impl<'hir> Sync for FnDecl<'hir>

impl<'hir> Sync for FnSig<'hir>

impl<'hir> Sync for ForeignItem<'hir>

impl<'hir> Sync for GenericArgs<'hir>

impl<'hir> Sync for GenericParam<'hir>

impl<'hir> Sync for Generics<'hir>

impl<'hir> Sync for Impl<'hir>

impl<'hir> Sync for ImplItem<'hir>

impl<'hir> Sync for InlineAsm<'hir>

impl<'hir> Sync for LetExpr<'hir>

impl<'hir> Sync for LetStmt<'hir>

impl<'hir> Sync for Mod<'hir>

impl<'hir> Sync for MutTy<'hir>

impl<'hir> Sync for OpaqueTy<'hir>

impl<'hir> Sync for Param<'hir>

impl<'hir> Sync for Pat<'hir>

impl<'hir> Sync for PatField<'hir>

impl<'hir> Sync for PathSegment<'hir>

impl<'hir> Sync for PolyTraitRef<'hir>

impl<'hir> Sync for Stmt<'hir>

impl<'hir> Sync for TraitItem<'hir>

impl<'hir> Sync for TraitRef<'hir>

impl<'hir> Sync for Ty<'hir>

impl<'hir> Sync for Variant<'hir>

impl<'hir> Sync for WhereBoundPredicate<'hir>

impl<'hir> Sync for WhereEqPredicate<'hir>

impl<'hir> Sync for WhereRegionPredicate<'hir>

impl<'hir, R> Sync for Path<'hir, R>
where R: Sync,

impl<'tcx> !Sync for MaybeOwner<'tcx>

impl<'tcx> !Sync for AttributeMap<'tcx>

impl<'tcx> !Sync for OwnerNodes<'tcx>

impl<'tcx> !Sync for ParentedNode<'tcx>

impl<'tcx> !Sync for Arena<'tcx>

impl<D> Sync for OpaqueTyOrigin<D>
where D: Sync,

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

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

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

impl Sync for FnKind

impl Sync for Context

impl Sync for RegionId

impl Sync for NamedVarMap

impl Sync for NestedSpan

impl Sync for Parameter

impl Sync for WildPatTy

impl Sync for InherentDyn

impl Sync for LinkageType

impl Sync for StartAsync

impl Sync for TyParamSome

impl Sync for VariancesOf

impl Sync for CurrentItem

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

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

impl<'a> Sync for AssocItemNotFoundLabel<'a>

impl<'a> Sync for AssocItemNotFoundSugg<'a>

impl<'a> Sync for RegionInferReason<'a>

impl<'a> Sync for VarianceTerm<'a>

impl<'a> Sync for CollectUsageSpans<'a>

impl<'a> Sync for AmbiguousAssocItem<'a>

impl<'a> Sync for AssocItemNotFound<'a>

impl<'a> Sync for CoerceUnsizedMay<'a>

impl<'a> Sync for CoerceUnsizedOneField<'a>

impl<'a> Sync for CrossCrateTraits<'a>

impl<'a> Sync for DispatchFromDynCoercion<'a>

impl<'a> Sync for DispatchFromDynSame<'a>

impl<'a> Sync for DispatchFromDynSingle<'a>

impl<'a> Sync for DispatchFromDynStruct<'a>

impl<'a> Sync for DispatchFromDynZST<'a>

impl<'a> Sync for InherentPrimitiveTy<'a>

impl<'a> Sync for InherentPrimitiveTyNote<'a>

impl<'a> Sync for OnlyCurrentTraitsName<'a>

impl<'a> Sync for OnlyCurrentTraitsTy<'a>

impl<'a> Sync for TraitsWithDefaultImpl<'a>

impl<'a> Sync for TransparentNonZeroSized<'a>

impl<'a> Sync for UnsupportedDelegation<'a>

impl<'a> Sync for Constraint<'a>

impl<'a, 'tcx> !Sync for Autoderef<'a, 'tcx>

impl<'a, 'tcx> !Sync for RemapLateBound<'a, 'tcx>

impl<'a, 'tcx> !Sync for InlineAsmCtxt<'a, 'tcx>

impl<'a, 'tcx> !Sync for WfCheckingCtxt<'a, 'tcx>

impl<'a, 'tcx> !Sync for BoundVarContext<'a, 'tcx>

impl<'a, 'tcx> !Sync for WrongNumberOfGenericArgs<'a, 'tcx>

impl<'a, 'tcx> !Sync for GenericParamAndBoundVarCollector<'a, 'tcx>

impl<'a, 'tcx> !Sync for ConstraintContext<'a, 'tcx>

impl<'a, 'tcx> !Sync for SolveContext<'a, 'tcx>

impl<'a, 'tcx> !Sync for TermsContext<'a, 'tcx>

impl<'a, 'tcx, E> !Sync for ImplTraitInTraitCollector<'a, 'tcx, E>

impl<'cx, 'tcx> !Sync for TyVarReplacer<'cx, 'tcx>

impl<'cx, 'tcx> !Sync for UncoveredTyParamCollector<'cx, 'tcx>

impl<'tcx> !Sync for Anonymize<'tcx>

impl<'tcx> !Sync for ImplTraitInTraitCollector<'tcx>

impl<'tcx> !Sync for RemapHiddenTyRegions<'tcx>

impl<'tcx> !Sync for ReplaceTy<'tcx>

impl<'tcx> !Sync for RegionResolutionVisitor<'tcx>

impl<'tcx> !Sync for HasErrorDeep<'tcx>

impl<'tcx> !Sync for IsProbablyCyclical<'tcx>

impl<'tcx> !Sync for Checker<'tcx>

impl<'tcx> !Sync for InherentCollect<'tcx>

impl<'tcx> !Sync for InherentOverlapChecker<'tcx>

impl<'tcx> !Sync for AssocTyToOpaque<'tcx>

impl<'tcx> !Sync for MapAndCompressBoundVars<'tcx>

impl<'tcx> !Sync for CollectItemTypesVisitor<'tcx>

impl<'tcx> !Sync for FieldUniquenessCheckContext<'tcx>

impl<'tcx> !Sync for ItemCtxt<'tcx>

impl<'tcx> !Sync for RpitConstraintChecker<'tcx>

impl<'tcx> !Sync for TaitConstraintLocator<'tcx>

impl<'tcx> !Sync for GenericArgsBuilder<'tcx>

impl<'tcx> !Sync for GenericsBuilder<'tcx>

impl<'tcx> !Sync for ParamIndexRemapper<'tcx>

impl<'tcx> !Sync for PredicatesBuilder<'tcx>

impl<'tcx> !Sync for ExplicitPredicatesMap<'tcx>

impl<'tcx> Sync for GenericsArgsErrExtend<'tcx>

impl<'tcx> Sync for AutoderefSnapshot<'tcx>

impl<'tcx> Sync for Bounds<'tcx>

impl<'tcx> Sync for GATArgsCollector<'tcx>

impl<'tcx> Sync for RedundantLifetimeArgsLint<'tcx>

impl<'tcx> Sync for InvalidGenericReceiverTy<'tcx>

impl<'tcx> Sync for InvalidReceiverTy<'tcx>

impl<'tcx> Sync for ParamInTyOfAssocConstBinding<'tcx>

impl<'tcx> Sync for ReturnTypeNotationOnNonRpitit<'tcx>

impl<'tcx> Sync for TyOfAssocConstBindingNote<'tcx>

impl<'tcx> Sync for TyParamFirstLocal<'tcx>

impl<'tcx> Sync for TyParamFirstLocalLint<'tcx>

impl<'tcx> Sync for TypeOf<'tcx>

impl<'tcx> Sync for TypeofReservedKeywordUsed<'tcx>

impl Sync for Nested

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

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

impl Sync for Diverges

impl Sync for Needs

impl Sync for PlaceOp

impl Sync for Issue

impl Sync for Mode

impl Sync for ProbeResult

impl Sync for ProbeScope

impl Sync for IsAssign

impl Sync for Op

impl Sync for AdjustMode

impl Sync for MutblCap

impl Sync for UseIsEmpty

impl Sync for ExpectedIdx

impl Sync for ProvidedIdx

impl Sync for TraitInfo

impl<'a> Sync for DeclOrigin<'a>

impl<'a> Sync for SelfSource<'a>

impl<'a> Sync for ConstSelectMustBeFn<'a>

impl<'a> Sync for Declaration<'a>

impl<'a, 'tcx> !Sync for Coerce<'a, 'tcx>

impl<'a, 'tcx> !Sync for AnnotateUnitFallbackVisitor<'a, 'tcx>

impl<'a, 'tcx> !Sync for NestedObligationsForSelfTy<'a, 'tcx>

impl<'a, 'tcx> !Sync for FnCtxt<'a, 'tcx>

impl<'a, 'tcx> !Sync for GatherLocalsVisitor<'a, 'tcx>

impl<'a, 'tcx> !Sync for ConfirmContext<'a, 'tcx>

impl<'a, 'tcx> !Sync for ProbeContext<'a, 'tcx>

impl<'a, 'tcx> !Sync for InferBorrowKindVisitor<'a, 'tcx>

impl<'a, 'tcx> Sync for PassToVariadicFunction<'a, 'tcx>

impl<'a, 'tcx> Sync for PatInfo<'a, 'tcx>

impl<'cx, 'tcx> !Sync for Resolver<'cx, 'tcx>

impl<'cx, 'tcx> !Sync for WritebackCx<'cx, 'tcx>

impl<'tcx> !Sync for FindClosureArg<'tcx>

impl<'tcx> !Sync for TypeckRootCtxt<'tcx>

impl<'tcx> !Sync for EagerlyNormalizeConsts<'tcx>

impl<'tcx> Sync for CallStep<'tcx>

impl<'tcx> Sync for CastError<'tcx>

impl<'tcx> Sync for PointerKind<'tcx>

impl<'tcx> Sync for TypeMismatchSource<'tcx>

impl<'tcx> Sync for ExpectedReturnTypeLabel<'tcx>

impl<'tcx> Sync for Expectation<'tcx>

impl<'tcx> Sync for Compatibility<'tcx>

impl<'tcx> Sync for Error<'tcx>

impl<'tcx> Sync for MethodError<'tcx>

impl<'tcx> Sync for CandidateKind<'tcx>

impl<'tcx> Sync for PickKind<'tcx>

impl<'tcx> Sync for DeferredCallResolution<'tcx>

impl<'tcx> Sync for CastCheck<'tcx>

impl<'tcx> Sync for ClosureSignatures<'tcx>

impl<'tcx> Sync for ExpectedSig<'tcx>

impl<'tcx> Sync for CannotCastToBool<'tcx>

impl<'tcx> Sync for CastEnumDrop<'tcx>

impl<'tcx> Sync for CastThinPointerToWidePointer<'tcx>

impl<'tcx> Sync for IntToWide<'tcx>

impl<'tcx> Sync for LossyProvenanceInt2Ptr<'tcx>

impl<'tcx> Sync for LossyProvenancePtr2Int<'tcx>

impl<'tcx> Sync for NoteCallerChoosesTyForTyParam<'tcx>

impl<'tcx> Sync for SuggestConvertViaMethod<'tcx>

impl<'tcx> Sync for TrivialCast<'tcx>

impl<'tcx> Sync for ArgMatrix<'tcx>

impl<'tcx> Sync for LoweredTy<'tcx>

impl<'tcx> Sync for ConfirmResult<'tcx>

impl<'tcx> Sync for Candidate<'tcx>

impl<'tcx> Sync for Pick<'tcx>

impl<'tcx> Sync for MethodCallee<'tcx>

impl<'tcx> Sync for NoMatchData<'tcx>

impl<'tcx> Sync for TopInfo<'tcx>

impl<'tcx> Sync for BreakableCtxt<'tcx>

impl<'tcx> Sync for CoroutineTypes<'tcx>

impl<'tcx> Sync for EnclosingBreakables<'tcx>

impl<'tcx> Sync for InferBorrowKind<'tcx>

impl<'tcx, 'exprs, E> Sync for Expressions<'tcx, 'exprs, E>
where E: Sync,

impl<'tcx, 'exprs, E> Sync for CoerceMany<'tcx, 'exprs, E>
where E: Sync,

impl<'tcx, Cx, D> !Sync for ExprUseVisitor<'tcx, Cx, D>

impl Sync for NoCfg

impl Sync for NoPath

impl Sync for Ok

impl Sync for UnknownItem

impl Sync for Assertion

impl<'a> Sync for AssertionAuto<'a>

impl<'a> Sync for CopyWorkProductToCache<'a>

impl<'a> Sync for CorruptFile<'a>

impl<'a> Sync for CreateDepGraph<'a>

impl<'a> Sync for CreateIncrCompDir<'a>

impl<'a> Sync for CreateLock<'a>

impl<'a> Sync for CreateNew<'a>

impl<'a> Sync for DeleteFull<'a>

impl<'a> Sync for DeleteLock<'a>

impl<'a> Sync for DeleteOld<'a>

impl<'a> Sync for DeletePartial<'a>

impl<'a> Sync for DeleteWorkProduct<'a>

impl<'a> Sync for Finalize<'a>

impl<'a> Sync for FinalizedGcFailed<'a>

impl<'a> Sync for HardLinkFailed<'a>

impl<'a> Sync for InvalidGcFailed<'a>

impl<'a> Sync for MoveDepGraph<'a>

impl<'a> Sync for NotClean<'a>

impl<'a> Sync for NotDirty<'a>

impl<'a> Sync for NotLoaded<'a>

impl<'a> Sync for RepeatedDepNodeLabel<'a>

impl<'a> Sync for SessionGcFailed<'a>

impl<'a> Sync for WriteNew<'a>

impl<'tcx> !Sync for IfThisChanged<'tcx>

impl<'tcx> !Sync for DirtyCleanVisitor<'tcx>

impl<'tcx> !Sync for FindAllAttrs<'tcx>

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

impl !Sync for Chunk

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

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

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

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

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

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

impl<R, C> Sync for BitMatrix<R, C>
where R: Sync, C: Sync,

impl<R, C> Sync for SparseBitMatrix<R, C>
where C: Sync,

impl<R, C> Sync for SparseIntervalMatrix<R, C>
where C: Sync,

impl<T> !Sync for ChunkedBitSet<T>

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

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

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

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

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

impl Sync for FixupError

impl<'a, 'tcx> !Sync for At<'a, 'tcx>

impl<'a, 'tcx> !Sync for RegionRelations<'a, 'tcx>

impl<'a, 'tcx> !Sync for TypeFreshener<'a, 'tcx>

impl<'a, 'tcx> !Sync for LeakCheck<'a, 'tcx>

impl<'a, 'tcx> !Sync for FullTypeResolver<'a, 'tcx>

impl<'a, 'tcx> !Sync for OpportunisticRegionResolver<'a, 'tcx>

impl<'a, 'tcx> !Sync for OpportunisticVarResolver<'a, 'tcx>

impl<'a, 'tcx> !Sync for InferenceFudger<'a, 'tcx>

impl<'a, 'tcx> Sync for OpaqueTypeTable<'a, 'tcx>

impl<'a, 'tcx> Sync for RegionConstraintCollector<'a, 'tcx>

impl<'a, 'tcx> Sync for TypeVariableTable<'a, 'tcx>

impl<'a, 'tcx> Sync for ProjectionCache<'a, 'tcx>

impl<'cx, 'tcx> !Sync for Canonicalizer<'cx, 'tcx>

impl<'cx, 'tcx> !Sync for LexicalResolver<'cx, 'tcx>

impl<'cx, 'tcx> !Sync for VerifyBoundCx<'cx, 'tcx>

impl<'cx, 'tcx, D> !Sync for TypeOutlives<'cx, 'tcx, D>

impl<'infcx, 'tcx> !Sync for LatticeOp<'infcx, 'tcx>

impl<'infcx, 'tcx> !Sync for TypeRelating<'infcx, 'tcx>

impl<'me, 'tcx> !Sync for Generalizer<'me, 'tcx>

impl<'tcx> !Sync for InferCtxt<'tcx>

impl<'tcx> !Sync for InferCtxtBuilder<'tcx>

impl<'tcx> !Sync for InferenceLiteralEraser<'tcx>

impl<'tcx> !Sync for PredicateSet<'tcx>

impl<'tcx> Sync for SubregionOrigin<'tcx>

impl<'tcx> Sync for ValuePairs<'tcx>

impl<'tcx> Sync for RegionResolutionError<'tcx>

impl<'tcx> Sync for VarValue<'tcx>

impl<'tcx> Sync for Constraint<'tcx>

impl<'tcx> Sync for GenericKind<'tcx>

impl<'tcx> Sync for UndoLog<'tcx>

impl<'tcx> Sync for VerifyBound<'tcx>

impl<'tcx> Sync for UndoLog<'tcx>

impl<'tcx> Sync for TypeVariableValue<'tcx>

impl<'tcx> Sync for ScrubbedTraitError<'tcx>

impl<'tcx> Sync for ProjectionCacheEntry<'tcx>

impl<'tcx> Sync for FreeRegionMap<'tcx>

impl<'tcx> Sync for LexicalRegionResolutions<'tcx>

impl<'tcx> Sync for RegionAndOrigin<'tcx>

impl<'tcx> Sync for OpaqueTypeDecl<'tcx>

impl<'tcx> Sync for OpaqueTypeStorage<'tcx>

impl<'tcx> Sync for OutlivesEnvironment<'tcx>

impl<'tcx> Sync for MiniGraph<'tcx>

impl<'tcx> Sync for SccUniverse<'tcx>

impl<'tcx> Sync for RegionConstraintData<'tcx>

impl<'tcx> Sync for RegionConstraintStorage<'tcx>

impl<'tcx> Sync for TwoRegions<'tcx>

impl<'tcx> Sync for Verify<'tcx>

impl<'tcx> Sync for VerifyIfEq<'tcx>

impl<'tcx> Sync for CombinedSnapshot<'tcx>

impl<'tcx> Sync for InferCtxtUndoLogs<'tcx>

impl<'tcx> Sync for Snapshot<'tcx>

impl<'tcx> Sync for InferCtxtInner<'tcx>

impl<'tcx> Sync for RegionObligation<'tcx>

impl<'tcx> Sync for TypeTrace<'tcx>

impl<'tcx> Sync for TyVidEqKey<'tcx>

impl<'tcx> Sync for TypeVariableStorage<'tcx>

impl<'tcx> Sync for MismatchedProjectionTypes<'tcx>

impl<'tcx> Sync for ProjectionCacheKey<'tcx>

impl<'tcx> Sync for ProjectionCacheStorage<'tcx>

impl<'tcx, OP> !Sync for ConstrainOpaqueTypeRegionVisitor<'tcx, OP>

impl<'tcx, OP> !Sync for FreeRegionsVisitor<'tcx, OP>

impl<'tcx, T> Sync for InferOk<'tcx, T>
where T: Sync,

impl<'tcx, T> Sync for Normalized<'tcx, T>
where T: Sync,

impl<'tcx, T> Sync for Obligation<'tcx, T>
where T: Sync,

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

impl !Sync for Compiler

impl !Sync for Config

impl !Sync for Linker

impl Sync for CantEmitMIR

impl Sync for OutDirError

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

impl<'a> Sync for FailedWritingFile<'a>

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

impl<'tcx> !Sync for Queries<'tcx>

impl<T> !Sync for Query<T>

impl Sync for Base

impl Sync for DocStyle

impl Sync for LiteralKind

impl Sync for RawStrError

impl Sync for TokenKind

impl Sync for EscapeError

impl Sync for MixedUnit

impl Sync for Mode

impl Sync for GuardedStr

impl Sync for Token

impl<'a> Sync for Cursor<'a>

impl !Sync for LintStore

impl Sync for TargetLint

impl Sync for SymbolName

impl Sync for ParamKind

impl Sync for MutRefSugg

impl Sync for CargoHelp

impl Sync for PatternKind

impl Sync for CItemKind

impl Sync for AsmLabels

impl Sync for InitError

impl Sync for MissingDoc

impl Sync for SoftLints

impl Sync for UnderMacro

impl Sync for UnsafeCode

impl Sync for WhileTrue

impl Sync for LintAlias

impl Sync for LintGroup

impl Sync for AltHead

impl Sync for Diagnostics

impl Sync for TyTyKind

impl Sync for TypeIr

impl Sync for BuilderPush

impl Sync for LintSet

impl Sync for TopDown

impl Sync for Expectation

impl Sync for MissingAbi

impl Sync for RawPrefix

impl Sync for TyQualified

impl Sync for TykindDiag

impl Sync for TykindKind

impl Sync for UnknownLint

impl Sync for UnusedLabel

impl Sync for WasmCAbi

impl Sync for Expr2024

impl Sync for MapUnitFn

impl Sync for NonPanicFmt

impl Sync for PassByValue

impl Sync for Precedence

impl Sync for TypeLimits

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

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

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

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

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

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

impl<'a> Sync for CheckLintNameResult<'a>

impl<'a> Sync for OverflowingBinHexSub<'a>

impl<'a> Sync for PtrNullChecksDiag<'a>

impl<'a> Sync for RenamedLintSuggestion<'a>

impl<'a> Sync for UseInclusiveRange<'a>

impl<'a> Sync for CheckNameUnknownTool<'a>

impl<'a> Sync for OverruledAttribute<'a>

impl<'a> Sync for RequestedLevel<'a>

impl<'a> Sync for BadOptAccessDiag<'a>

impl<'a> Sync for BuiltinAnonymousParams<'a>

impl<'a> Sync for BuiltinMissingDoc<'a>

impl<'a> Sync for BuiltinTrivialBounds<'a>

impl<'a> Sync for BuiltinUnreachablePub<'a>

impl<'a> Sync for BuiltinUnusedDocComment<'a>

impl<'a> Sync for DefaultHashTypesDiag<'a>

impl<'a> Sync for DeprecatedLintName<'a>

impl<'a> Sync for DropCopyDiag<'a>

impl<'a> Sync for DropRefDiag<'a>

impl<'a> Sync for ForgetCopyDiag<'a>

impl<'a> Sync for ForgetRefDiag<'a>

impl<'a> Sync for ImproperCTypes<'a>

impl<'a> Sync for NonCamelCaseType<'a>

impl<'a> Sync for NonSnakeCaseDiag<'a>

impl<'a> Sync for NonUpperCaseGlobal<'a>

impl<'a> Sync for NoopMethodCallDiag<'a>

impl<'a> Sync for OverflowingBinHex<'a>

impl<'a> Sync for OverflowingInt<'a>

impl<'a> Sync for OverflowingIntHelp<'a>

impl<'a> Sync for OverflowingLiteral<'a>

impl<'a> Sync for OverflowingUInt<'a>

impl<'a> Sync for OverruledAttributeLint<'a>

impl<'a> Sync for RangeEndpointOutOfRange<'a>

impl<'a> Sync for RefOfMutStatic<'a>

impl<'a> Sync for RemovedLint<'a>

impl<'a> Sync for RenamedLint<'a>

impl<'a> Sync for SupertraitAsDerefTarget<'a>

impl<'a> Sync for UnusedClosure<'a>

impl<'a> Sync for UnusedCoroutine<'a>

impl<'a> Sync for UnusedDelim<'a>

impl<'a> Sync for UnusedOp<'a>

impl<'a> Sync for UnusedResult<'a>

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

impl<'a, 'tcx> !Sync for RuntimeCombinedLateLintPass<'a, 'tcx>

impl<'a, 'tcx> !Sync for LintTailExpr<'a, 'tcx>

impl<'a, 'tcx> !Sync for LintVisitor<'a, 'tcx>

impl<'a, 'tcx> !Sync for LocalCollector<'a, 'tcx>

impl<'a, 'tcx> !Sync for ImproperCTypesVisitor<'a, 'tcx>

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

impl<'hir> Sync for BuiltinTypeAliasBounds<'hir>

impl<'lcx, 'tcx> !Sync for DanglingPointerSearcher<'lcx, 'tcx>

impl<'s, P> !Sync for LintLevelsBuilder<'s, P>

impl<'tcx> !Sync for LateContext<'tcx>

impl<'tcx> !Sync for FunctionalVariances<'tcx>

impl<'tcx> !Sync for LintLevelMaximum<'tcx>

impl<'tcx> !Sync for LintLevelQueryMap<'tcx>

impl<'tcx> Sync for InvalidReferenceCastingDiag<'tcx>

impl<'tcx> Sync for FfiResult<'tcx>

impl<'tcx> Sync for ImplTraitOvercapturesLint<'tcx>

impl<'tcx> Sync for PathCollector<'tcx>

impl<'tcx> Sync for AddBound<'tcx>

impl<'tcx> Sync for OpaqueHiddenInferredBoundLint<'tcx>

impl<'tcx> Sync for CTypesVisitorState<'tcx>

impl<'tcx, 'a> !Sync for FindSignificantDropper<'tcx, 'a>

impl<'tcx, T> !Sync for LateContextAndPass<'tcx, T>

impl<'tcx, VarFn, OutlivesFn> !Sync for VisitOpaqueTypes<'tcx, VarFn, OutlivesFn>

impl Sync for Level

impl Sync for Lint

impl Sync for LintBuffer

impl Sync for LintId

impl Sync for Error

impl !Sync for LoadedMacro

impl !Sync for CStore

impl Sync for DylibError

impl Sync for LoadResult

impl Sync for CrateError

impl Sync for CrateFlavor

impl Sync for LazyState

impl Sync for SpanKind

impl Sync for Library

impl Sync for DlError

impl Sync for LinkCfgForm

impl Sync for CratePaths

impl Sync for AttrFlags

impl Sync for CrateDep

impl Sync for CrateHeader

impl Sync for CrateRoot

impl Sync for LazyTables

impl Sync for RawDefId

impl Sync for SpanTag

impl Sync for TraitImpls

impl Sync for VariantData

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

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

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

impl<'a> Sync for MetadataError<'a>

impl<'a> Sync for EmptyRenamingTarget<'a>

impl<'a> Sync for ExternLocationNotExist<'a>

impl<'a> Sync for ExternLocationNotFile<'a>

impl<'a> Sync for FailWriteFile<'a>

impl<'a> Sync for FailedCreateFile<'a>

impl<'a> Sync for LibFilenameForm<'a>

impl<'a> Sync for LibRequired<'a>

impl<'a> Sync for MissingNativeLibrary<'a>

impl<'a> Sync for MultipleModifiers<'a>

impl<'a> Sync for MultipleRenamings<'a>

impl<'a> Sync for NoCrateWithTriple<'a>

impl<'a> Sync for NoTransitiveNeedsDep<'a>

impl<'a> Sync for RenamingNoLink<'a>

impl<'a> Sync for RustcLibRequired<'a>

impl<'a> Sync for SuggestLibraryName<'a>

impl<'a> Sync for UnknownImportNameType<'a>

impl<'a> Sync for UnknownLinkKind<'a>

impl<'a> Sync for UnknownLinkModifier<'a>

impl<'a> Sync for AnalyzeAttrState<'a>

impl<'a, 'tcx> !Sync for CrateLoader<'a, 'tcx>

impl<'a, 'tcx> !Sync for DecodeContext<'a, 'tcx>

impl<'a, 'tcx> !Sync for EncodeContext<'a, 'tcx>

impl<'a, 'tcx, T> !Sync for DecodeIterator<'a, 'tcx, T>

impl<'tcx> !Sync for Collector<'tcx>

impl<'tcx> Sync for DefPathHashMapRef<'tcx>

impl<I, T> Sync for LazyTable<I, T>

impl<I, T> Sync for TableBuilder<I, T>
where T: Sync, <T as FixedSizeEncoding>::ByteArray: Sync,

impl<T> Sync for LazyArray<T>

impl<T> Sync for LazyValue<T>

impl !Sync for CurrentGcx

impl Sync for DepKindDefs

impl Sync for PlaceBase

impl Sync for Certainty

impl Sync for Reexport

impl Sync for Linkage

impl Sync for Level

impl Sync for ScopeData

impl Sync for ResolvedArg

impl Sync for EvalResult

impl Sync for CovTerm

impl Sync for MappingKind

impl Sync for Op

impl Sync for DefLocation

impl Sync for LocalKind

impl Sync for AllocError

impl Sync for InitChunk

impl Sync for State

impl Sync for PointerKind

impl Sync for Linkage

impl Sync for Visibility

impl Sync for PassWhere

impl Sync for BinOp

impl Sync for BorrowKind

impl Sync for CallSource

impl Sync for CastKind

impl Sync for MirPhase

impl Sync for RetagKind

impl Sync for UnOp

impl Sync for TyContext

impl Sync for BlockSafety

impl Sync for LintLevel

impl Sync for LogicalOp

impl Sync for IsConstable

impl Sync for Node

impl Sync for OverlapMode

impl Sync for CastKind

impl Sync for Adjust

impl Sync for AutoBorrow

impl Sync for AdtKind

impl Sync for AssocKind

impl Sync for CastKind

impl Sync for IntTy

impl Sync for BorrowKind

impl Sync for FeedConstTy

impl Sync for ExprKind

impl Sync for Asyncness

impl Sync for ParamTerm

impl Sync for TermVid

impl Sync for ReifyReason

impl Sync for BoundTyKind

impl Sync for DepsType

impl Sync for All

impl Sync for OnlyBodies

impl Sync for ModuleItems

impl Sync for Providers

impl Sync for ModChild

impl Sync for LibFeatures

impl Sync for Scope

impl Sync for ScopeTree

impl Sync for YieldData

impl Sync for Deprecated

impl Sync for Index

impl Sync for Cache

impl Sync for BranchSpan

impl Sync for ConditionId

impl Sync for CounterId

impl Sync for Expression

impl Sync for Mapping

impl Sync for InitCopy

impl Sync for InitMask

impl Sync for AllocRange

impl Sync for Guard

impl Sync for AllocId

impl Sync for BasicBlock

impl Sync for Local

impl Sync for Location

impl Sync for Promoted

impl Sync for SourceInfo

impl Sync for SourceScope

impl Sync for LocalCrate

impl Sync for Footer

impl Sync for Providers

impl Sync for QueryEngine

impl Sync for ArmId

impl Sync for Block

impl Sync for BlockId

impl Sync for ExprId

impl Sync for FieldExpr

impl Sync for LocalVarId

impl Sync for ParamId

impl Sync for StmtId

impl Sync for Children

impl Sync for Graph

impl Sync for LeafDef

impl Sync for AdtDefData

impl Sync for AdtFlags

impl Sync for AssocItem

impl Sync for AssocItems

impl Sync for CaptureInfo

impl Sync for UpvarId

impl Sync for UpvarPath

impl Sync for ConstInt

impl Sync for ScalarInt

impl Sync for Generics

impl Sync for TypeInfo

impl Sync for BoundRegion

impl Sync for Destructor

impl Sync for FieldDef

impl Sync for ParamTag

impl Sync for VariantDef

impl Sync for BoundTy

impl Sync for ParamConst

impl Sync for ParamTy

impl Sync for TraitDef

impl Sync for TraitImpls

impl Sync for MaxUniverse

impl Sync for Providers

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

impl<'a> Sync for LimitInvalid<'a>

impl<'a> Sync for InitChunkIter<'a>

impl<'a> Sync for SwitchTargetsIter<'a>

impl<'a> Sync for LocalSetInContext<'a>

impl<'a> Sync for LocalSetInContextMut<'a>

impl<'a, 'tcx> !Sync for MonoReachable<'a, 'tcx>

impl<'a, 'tcx> !Sync for CacheDecoder<'a, 'tcx>

impl<'a, 'tcx> !Sync for CacheEncoder<'a, 'tcx>

impl<'a, 'tcx> !Sync for FnMutDelegate<'a, 'tcx>

impl<'a, 'tcx> !Sync for RegionFolder<'a, 'tcx>

impl<'a, 'tcx> !Sync for FmtPrinter<'a, 'tcx>

impl<'a, 'tcx> !Sync for FmtPrinterData<'a, 'tcx>

impl<'a, 'tcx> !Sync for RegionFolder<'a, 'tcx>

impl<'a, 'tcx> !Sync for ImplicitCtxt<'a, 'tcx>

impl<'a, 'tcx> Sync for CallReturnPlaces<'a, 'tcx>

impl<'a, 'tcx> Sync for Preorder<'a, 'tcx>

impl<'a, 'tcx, C> Sync for Postorder<'a, 'tcx, C>
where C: Sync,

impl<'a, G, NodeContentFn, EdgeLabelsFn> Sync for GraphvizWriter<'a, G, NodeContentFn, EdgeLabelsFn>
where NodeContentFn: Sync, EdgeLabelsFn: Sync, G: Sync,

impl<'a, V> Sync for LocalTableInContext<'a, V>
where V: Sync,

impl<'a, V> Sync for LocalTableInContextMut<'a, V>
where V: Sync,

impl<'hir> !Sync for Map<'hir>

impl<'hir> !Sync for ParentHirIterator<'hir>

impl<'hir> !Sync for ParentOwnerIterator<'hir>

impl<'mir, 'tcx> Sync for TerminatorEdges<'mir, 'tcx>

impl<'s> !Sync for AllocDecodingSession<'s>

impl<'sess> !Sync for OnDiskCache<'sess>

impl<'tcx> !Sync for InterpErrorKind<'tcx>

impl<'tcx> !Sync for UndefinedBehaviorInfo<'tcx>

impl<'tcx> !Sync for Arena<'tcx>

impl<'tcx> !Sync for ItemCollector<'tcx>

impl<'tcx> !Sync for CanonicalParamEnvCache<'tcx>

impl<'tcx> !Sync for InterpErrorInfo<'tcx>

impl<'tcx> !Sync for InterpErrorInfoInner<'tcx>

impl<'tcx> !Sync for CodegenUnitNameBuilder<'tcx>

impl<'tcx> !Sync for ExtraComments<'tcx>

impl<'tcx> !Sync for QuerySystem<'tcx>

impl<'tcx> !Sync for TyCtxtAt<'tcx>

impl<'tcx> !Sync for TyCtxtEnsure<'tcx>

impl<'tcx> !Sync for TyCtxtEnsureWithValue<'tcx>

impl<'tcx> !Sync for DynamicQueries<'tcx>

impl<'tcx> !Sync for QueryArenas<'tcx>

impl<'tcx> !Sync for QueryCaches<'tcx>

impl<'tcx> !Sync for QueryStates<'tcx>

impl<'tcx> !Sync for CtxtInterners<'tcx>

impl<'tcx> !Sync for GlobalCtxt<'tcx>

impl<'tcx> !Sync for TyCtxt<'tcx>

impl<'tcx> !Sync for IsSuggestableVisitor<'tcx>

impl<'tcx> !Sync for MakeSuggestableFolder<'tcx>

impl<'tcx> !Sync for StaticLifetimeVisitor<'tcx>

impl<'tcx> !Sync for TraitObjectVisitor<'tcx>

impl<'tcx> !Sync for RegionEraserVisitor<'tcx>

impl<'tcx> !Sync for LayoutCx<'tcx>

impl<'tcx> !Sync for ReverseMapper<'tcx>

impl<'tcx> !Sync for ImplTraitHeader<'tcx>

impl<'tcx> !Sync for OpaqueTypeExpander<'tcx>

impl<'tcx> !Sync for WeakAliasTypeExpander<'tcx>

impl<'tcx> Sync for LayoutError<'tcx>

impl<'tcx> Sync for ConstVariableValue<'tcx>

impl<'tcx> Sync for RegionVariableValue<'tcx>

impl<'tcx> Sync for ExportedSymbol<'tcx>

impl<'tcx> Sync for Const<'tcx>

impl<'tcx> Sync for ConstValue<'tcx>

impl<'tcx> Sync for BindingForm<'tcx>

impl<'tcx> Sync for LocalInfo<'tcx>

impl<'tcx> Sync for MentionedItem<'tcx>

impl<'tcx> Sync for VarDebugInfoContents<'tcx>

impl<'tcx> Sync for GlobalAlloc<'tcx>

impl<'tcx> Sync for InvalidProgramInfo<'tcx>

impl<'tcx> Sync for ValidationErrorKind<'tcx>

impl<'tcx> Sync for MonoItem<'tcx>

impl<'tcx> Sync for ClosureOutlivesSubject<'tcx>

impl<'tcx> Sync for ConstraintCategory<'tcx>

impl<'tcx> Sync for AggregateKind<'tcx>

impl<'tcx> Sync for InlineAsmOperand<'tcx>

impl<'tcx> Sync for NonDivergingIntrinsic<'tcx>

impl<'tcx> Sync for NullOp<'tcx>

impl<'tcx> Sync for Operand<'tcx>

impl<'tcx> Sync for Rvalue<'tcx>

impl<'tcx> Sync for StatementKind<'tcx>

impl<'tcx> Sync for TerminatorKind<'tcx>

impl<'tcx> Sync for BodyTy<'tcx>

impl<'tcx> Sync for ExprKind<'tcx>

impl<'tcx> Sync for InlineAsmOperand<'tcx>

impl<'tcx> Sync for PatKind<'tcx>

impl<'tcx> Sync for PatRangeBoundary<'tcx>

impl<'tcx> Sync for StmtKind<'tcx>

impl<'tcx> Sync for ObligationCauseCode<'tcx>

impl<'tcx> Sync for SelectionError<'tcx>

impl<'tcx> Sync for OutlivesBound<'tcx>

impl<'tcx> Sync for SelectionCandidate<'tcx>

impl<'tcx> Sync for CastTy<'tcx>

impl<'tcx> Sync for ValTree<'tcx>

impl<'tcx> Sync for ImplSubject<'tcx>

impl<'tcx> Sync for InhabitedPredicate<'tcx>

impl<'tcx> Sync for InstanceKind<'tcx>

impl<'tcx> Sync for FnAbiError<'tcx>

impl<'tcx> Sync for FnAbiRequest<'tcx>

impl<'tcx> Sync for LayoutError<'tcx>

impl<'tcx> Sync for SizeSkeleton<'tcx>

impl<'tcx> Sync for NormalizationError<'tcx>

impl<'tcx> Sync for PatternKind<'tcx>

impl<'tcx> Sync for UpvarArgs<'tcx>

impl<'tcx> Sync for UserType<'tcx>

impl<'tcx> Sync for ExplicitSelf<'tcx>

impl<'tcx> Sync for NotUniqueParam<'tcx>

impl<'tcx> Sync for VtblEntry<'tcx>

impl<'tcx> Sync for CallKind<'tcx>

impl<'tcx> Sync for DropCheckOverflow<'tcx>

impl<'tcx> Sync for OpaqueHiddenTypeMismatch<'tcx>

impl<'tcx> Sync for RecursionLimitReached<'tcx>

impl<'tcx> Sync for Place<'tcx>

impl<'tcx> Sync for PlaceWithHirId<'tcx>

impl<'tcx> Sync for Projection<'tcx>

impl<'tcx> Sync for OriginalQueryValues<'tcx>

impl<'tcx> Sync for QueryRegionConstraints<'tcx>

impl<'tcx> Sync for MemberConstraint<'tcx>

impl<'tcx> Sync for ConstVidKey<'tcx>

impl<'tcx> Sync for RegionVidKey<'tcx>

impl<'tcx> Sync for BasicBlocks<'tcx>

impl<'tcx> Sync for ConstAlloc<'tcx>

impl<'tcx> Sync for UnevaluatedConst<'tcx>

impl<'tcx> Sync for ConstAllocation<'tcx>

impl<'tcx> Sync for ValidationErrorInfo<'tcx>

impl<'tcx> Sync for AllocMap<'tcx>

impl<'tcx> Sync for GlobalId<'tcx>

impl<'tcx> Sync for LitToConstInput<'tcx>

impl<'tcx> Sync for CodegenUnit<'tcx>

impl<'tcx> Sync for MirPatch<'tcx>

impl<'tcx> Sync for BorrowCheckResult<'tcx>

impl<'tcx> Sync for ClosureOutlivesRequirement<'tcx>

impl<'tcx> Sync for ClosureOutlivesSubjectTy<'tcx>

impl<'tcx> Sync for ClosureRegionRequirements<'tcx>

impl<'tcx> Sync for CoroutineLayout<'tcx>

impl<'tcx> Sync for CoroutineSavedTy<'tcx>

impl<'tcx> Sync for DestructuredConstant<'tcx>

impl<'tcx> Sync for PlaceRef<'tcx>

impl<'tcx> Sync for Statement<'tcx>

impl<'tcx> Sync for BasicBlockData<'tcx>

impl<'tcx> Sync for Body<'tcx>

impl<'tcx> Sync for CoroutineInfo<'tcx>

impl<'tcx> Sync for LocalDecl<'tcx>

impl<'tcx> Sync for MirSource<'tcx>

impl<'tcx> Sync for SourceScopeData<'tcx>

impl<'tcx> Sync for VarBindingForm<'tcx>

impl<'tcx> Sync for VarDebugInfo<'tcx>

impl<'tcx> Sync for VarDebugInfoFragment<'tcx>

impl<'tcx> Sync for ConstOperand<'tcx>

impl<'tcx> Sync for CopyNonOverlapping<'tcx>

impl<'tcx> Sync for Place<'tcx>

impl<'tcx> Sync for PlaceTy<'tcx>

impl<'tcx> Sync for Terminator<'tcx>

impl<'tcx> Sync for QuerySystemFns<'tcx>

impl<'tcx> Sync for AdtExpr<'tcx>

impl<'tcx> Sync for Arm<'tcx>

impl<'tcx> Sync for Ascription<'tcx>

impl<'tcx> Sync for ClosureExpr<'tcx>

impl<'tcx> Sync for Expr<'tcx>

impl<'tcx> Sync for FieldPat<'tcx>

impl<'tcx> Sync for FruInfo<'tcx>

impl<'tcx> Sync for InlineAsmExpr<'tcx>

impl<'tcx> Sync for Param<'tcx>

impl<'tcx> Sync for Pat<'tcx>

impl<'tcx> Sync for PatRange<'tcx>

impl<'tcx> Sync for Stmt<'tcx>

impl<'tcx> Sync for Thir<'tcx>

impl<'tcx> Sync for CandidateStep<'tcx>

impl<'tcx> Sync for DropckConstraint<'tcx>

impl<'tcx> Sync for DropckOutlivesResult<'tcx>

impl<'tcx> Sync for MethodAutoderefBadTy<'tcx>

impl<'tcx> Sync for MethodAutoderefStepsResult<'tcx>

impl<'tcx> Sync for NormalizationResult<'tcx>

impl<'tcx> Sync for AscribeUserType<'tcx>

impl<'tcx> Sync for DropckOutlives<'tcx>

impl<'tcx> Sync for Eq<'tcx>

impl<'tcx> Sync for ImpliedOutlivesBounds<'tcx>

impl<'tcx> Sync for ProvePredicate<'tcx>

impl<'tcx> Sync for Subtype<'tcx>

impl<'tcx> Sync for ExternalConstraints<'tcx>

impl<'tcx> Sync for PredefinedOpaques<'tcx>

impl<'tcx> Sync for Ancestors<'tcx>

impl<'tcx> Sync for DerivedCause<'tcx>

impl<'tcx> Sync for IfExpressionCause<'tcx>

impl<'tcx> Sync for ImplDerivedCause<'tcx>

impl<'tcx> Sync for InternedObligationCauseCode<'tcx>

impl<'tcx> Sync for MatchExpressionArmCause<'tcx>

impl<'tcx> Sync for ObligationCause<'tcx>

impl<'tcx> Sync for SignatureMismatchData<'tcx>

impl<'tcx> Sync for UnifyReceiverContext<'tcx>

impl<'tcx> Sync for Adjustment<'tcx>

impl<'tcx> Sync for AdtDef<'tcx>

impl<'tcx> Sync for CapturedPlace<'tcx>

impl<'tcx> Sync for ClosureTypeInfo<'tcx>

impl<'tcx> Sync for Expr<'tcx>

impl<'tcx> Sync for Const<'tcx>

impl<'tcx> Sync for CommonConsts<'tcx>

impl<'tcx> Sync for CommonLifetimes<'tcx>

impl<'tcx> Sync for CommonTypes<'tcx>

impl<'tcx> Sync for UserArgs<'tcx>

impl<'tcx> Sync for UserSelfTy<'tcx>

impl<'tcx> Sync for ConstConditions<'tcx>

impl<'tcx> Sync for GenericPredicates<'tcx>

impl<'tcx> Sync for Instance<'tcx>

impl<'tcx> Sync for ShortInstance<'tcx>

impl<'tcx> Sync for Pattern<'tcx>

impl<'tcx> Sync for Clause<'tcx>

impl<'tcx> Sync for Predicate<'tcx>

impl<'tcx> Sync for OpaqueFnEntry<'tcx>

impl<'tcx> Sync for PrintClosureAsImpl<'tcx>

impl<'tcx> Sync for RegionHighlightMode<'tcx>

impl<'tcx> Sync for TraitRefPrintOnlyTraitName<'tcx>

impl<'tcx> Sync for TraitRefPrintOnlyTraitPath<'tcx>

impl<'tcx> Sync for TraitRefPrintSugared<'tcx>

impl<'tcx> Sync for Region<'tcx>

impl<'tcx> Sync for BoundConst<'tcx>

impl<'tcx> Sync for ClosureSizeProfileData<'tcx>

impl<'tcx> Sync for CratePredicatesMap<'tcx>

impl<'tcx> Sync for CrateVariancesMap<'tcx>

impl<'tcx> Sync for DestructuredConst<'tcx>

impl<'tcx> Sync for ImplHeader<'tcx>

impl<'tcx> Sync for InstantiatedPredicates<'tcx>

impl<'tcx> Sync for OpaqueHiddenType<'tcx>

impl<'tcx> Sync for ParamEnv<'tcx>

impl<'tcx> Sync for SymbolName<'tcx>

impl<'tcx> Sync for Ty<'tcx>

impl<'tcx> Sync for InlineConstArgs<'tcx>

impl<'tcx> Sync for CanonicalUserTypeAnnotation<'tcx>

impl<'tcx> Sync for TypeckResults<'tcx>

impl<'tcx> Sync for Discr<'tcx>

impl<'tcx> Sync for TypeWalker<'tcx>

impl<'tcx, C> !Sync for DynamicQuery<'tcx, C>

impl<'tcx, D> !Sync for BoundVarReplacer<'tcx, D>

impl<'tcx, F, G, H> !Sync for BottomUpFolder<'tcx, F, G, H>

impl<'tcx, KEY> !Sync for Feed<'tcx, KEY>

impl<'tcx, KEY> !Sync for TyCtxtFeed<'tcx, KEY>

impl<'tcx, N> Sync for ImplSource<'tcx, N>
where N: Sync,

impl<'tcx, N> Sync for ImplSourceUserDefinedData<'tcx, N>
where N: Sync,

impl<'tcx, R> Sync for QueryResponse<'tcx, R>
where R: Sync,

impl<'tcx, T> !Sync for InterpResult_<'tcx, T>

impl<'tcx, T> Sync for InternedInSet<'tcx, T>
where T: Sync + ?Sized,

impl<'tcx, T> Sync for ParamEnvAnd<'tcx, T>
where T: Sync,

impl<'tcx, T> Sync for InlineConstArgsParts<'tcx, T>
where T: Sync,

impl<H, T> Sync for ListSkeleton<H, T>
where H: Sync, T: Sync,

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

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

impl<O> Sync for AssertKind<O>
where O: Sync,

impl<Prov> Sync for Scalar<Prov>
where Prov: Sync,

impl<Prov> Sync for ProvenanceCopy<Prov>
where Prov: Sync,

impl<Prov> Sync for ProvenanceMap<Prov>
where Prov: Sync,

impl<Prov> Sync for Pointer<Prov>
where Prov: Sync,

impl<Prov, Extra, Bytes> Sync for Allocation<Prov, Extra, Bytes>
where Bytes: Sync, Extra: Sync, Prov: Sync,

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

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

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

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

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

impl<V, T> Sync for ProjectionElem<V, T>
where T: Sync, V: Sync,

impl Sync for BlockFrame

impl Sync for ForGuard

impl Sync for PlaceBase

impl Sync for Category

impl Sync for RvalueFunc

impl Sync for DropKind

impl Sync for Conflict

impl Sync for SuggestLet

impl Sync for LetSource

impl Sync for MCDCState

impl Sync for BranchInfo

impl Sync for NotInfo

impl Sync for ParseError

impl Sync for ArmHasGuard

impl Sync for DropData

impl Sync for DropIdx

impl Sync for DropNode

impl Sync for DropNodeKey

impl Sync for DropTree

impl Sync for ExitScopes

impl Sync for IfThenScope

impl Sync for Scope

impl Sync for Unwind

impl Sync for GuardFrame

impl Sync for ScopeId

impl Sync for Inform

impl Sync for NaNPattern

impl Sync for Variant

impl<'a, 'b, 'tcx> !Sync for FakeBorrowCollector<'a, 'b, 'tcx>

impl<'a, 'tcx> !Sync for ParseCtxt<'a, 'tcx>

impl<'a, 'tcx> !Sync for Builder<'a, 'tcx>

impl<'a, 'tcx> !Sync for LayoutConstrainedPlaceVisitor<'a, 'tcx>

impl<'a, 'tcx> !Sync for UnsafetyVisitor<'a, 'tcx>

impl<'a, 'tcx> !Sync for PatCtxt<'a, 'tcx>

impl<'a, 'tcx> Sync for ThirPrinter<'a, 'tcx>

impl<'mir, 'tcx, C> !Sync for Search<'mir, 'tcx, C>

impl<'p, 'tcx> !Sync for MatchVisitor<'p, 'tcx>

impl<'p, 'tcx, 'm> !Sync for NonExhaustivePatternsTypeNotEmpty<'p, 'tcx, 'm>

impl<'pat, 'tcx> Sync for TestCase<'pat, 'tcx>

impl<'pat, 'tcx> Sync for Candidate<'pat, 'tcx>

impl<'pat, 'tcx> Sync for FlatPat<'pat, 'tcx>

impl<'pat, 'tcx> Sync for MatchPairTree<'pat, 'tcx>

impl<'s, 'tcx> Sync for PatternNotCovered<'s, 'tcx>

impl<'tcx> !Sync for Cx<'tcx>

impl<'tcx> !Sync for ConstToPat<'tcx>

impl<'tcx> Sync for TestBranch<'tcx>

impl<'tcx> Sync for TestKind<'tcx>

impl<'tcx> Sync for PlaceBuilder<'tcx>

impl<'tcx> Sync for Ascription<'tcx>

impl<'tcx> Sync for Binding<'tcx>

impl<'tcx> Sync for BuiltMatchTree<'tcx>

impl<'tcx> Sync for MatchTreeBranch<'tcx>

impl<'tcx> Sync for MatchTreeSubBranch<'tcx>

impl<'tcx> Sync for PatternExtraData<'tcx>

impl<'tcx> Sync for Test<'tcx>

impl<'tcx> Sync for BreakableScope<'tcx>

impl<'tcx> Sync for Scopes<'tcx>

impl<'tcx> Sync for CFG<'tcx>

impl<'tcx> Sync for Capture<'tcx>

impl<'tcx> Sync for AdtDefinedHere<'tcx>

impl<'tcx> Sync for BorrowOfMovedValue<'tcx>

impl<'tcx> Sync for InvalidPattern<'tcx>

impl<'tcx> Sync for LiteralOutOfRange<'tcx>

impl<'tcx> Sync for NonEmptyNeverPattern<'tcx>

impl<'tcx> Sync for TypeNotPartialEq<'tcx>

impl<'tcx> Sync for TypeNotStructural<'tcx>

impl<'tcx> Sync for UnreachablePattern<'tcx>

impl<'tcx> Sync for UnsizedPattern<'tcx>

impl<'tcx> Sync for CallRecursion<'tcx>

impl<'tcx> Sync for RecursiveDrop<'tcx>

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

impl Sync for DropStyle

impl Sync for Unwind

impl Sync for Effect

impl Sync for Background

impl Sync for OutputStyle

impl Sync for DefUse

impl Sync for InitKind

impl Sync for TrackElem

impl Sync for Backward

impl Sync for Forward

impl Sync for CfgEdge

impl Sync for EffectIndex

impl Sync for Init

impl Sync for InitIndex

impl Sync for MoveOut

impl Sync for PointIndex

impl Sync for PeekCall

impl Sync for PlaceIndex

impl Sync for ValueIndex

impl<'a> Sync for TransferFunction<'a>

impl<'a> Sync for YieldResumeEffect<'a>

impl<'a> Sync for MaybeStorageDead<'a>

impl<'a> Sync for MaybeStorageLive<'a>

impl<'a, 'b, 'tcx, D> Sync for DropCtxt<'a, 'b, 'tcx, D>
where <D as DropElaborator<'b, 'tcx>>::Path: Sync, D: Sync,

impl<'a, 'mir, 'tcx> Sync for MoveVisitor<'a, 'mir, 'tcx>

impl<'a, 'mir, 'tcx, A> Sync for BlockFormatter<'a, 'mir, 'tcx, A>
where <A as Analysis<'tcx>>::Domain: Sync, A: Sync,

impl<'a, 'tcx> !Sync for MaybeInitializedPlaces<'a, 'tcx>

impl<'a, 'tcx> !Sync for MaybeUninitializedPlaces<'a, 'tcx>

impl<'a, 'tcx> !Sync for PlaceCollector<'a, 'tcx>

impl<'a, 'tcx> Sync for DefinitelyInitializedPlaces<'a, 'tcx>

impl<'a, 'tcx> Sync for EverInitializedPlaces<'a, 'tcx>

impl<'a, 'tcx> Sync for ProjectionIter<'a, 'tcx>

impl<'a, 'tcx> Sync for Children<'a, 'tcx>

impl<'a, 'tcx, F> !Sync for MoveDataBuilder<'a, 'tcx, F>

impl<'a, 'tcx, F> Sync for MovePathLinearIter<'a, 'tcx, F>
where F: Sync,

impl<'a, N> Sync for Visitor<'a, N>

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

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

impl<'a, T, C> Sync for DebugDiffWithAdapter<'a, T, C>
where T: Sync, C: Sync,

impl<'a, T, C> Sync for DebugWithAdapter<'a, T, C>
where T: Sync, C: Sync,

impl<'mir, 'tcx> Sync for MaybeRequiresStorage<'mir, 'tcx>

impl<'mir, 'tcx, A> !Sync for Formatter<'mir, 'tcx, A>

impl<'mir, 'tcx, A> Sync for ResultsCursor<'mir, 'tcx, A>
where <A as Analysis<'tcx>>::Domain: Sync, A: Sync,

impl<'mir, 'tcx, D, F> Sync for BackwardSwitchIntEdgeEffectsApplier<'mir, 'tcx, D, F>
where D: Sync, F: Sync,

impl<'mir, D, F> Sync for ForwardSwitchIntEdgeEffectsApplier<'mir, D, F>
where F: Sync, D: Sync,

impl<'tcx> Sync for MoveData<'tcx>

impl<'tcx> Sync for MovePath<'tcx>

impl<'tcx> Sync for MovePathLookup<'tcx>

impl<'tcx> Sync for MoveDataParamEnv<'tcx>

impl<'tcx> Sync for UnDerefer<'tcx>

impl<'tcx> Sync for Map<'tcx>

impl<'tcx> Sync for PlaceInfo<'tcx>

impl<'tcx, A> Sync for Results<'tcx, A>
where A: Sync, <A as Analysis<'tcx>>::Domain: Sync,

impl<D> Sync for StateDiffCollector<D>
where D: Sync,

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

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

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

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

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

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

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

impl Sync for Operation

impl Sync for BcbCounter

impl Sync for ConstMutate

impl Sync for AddressKind

impl Sync for Polarity

impl Sync for Update

impl Sync for TempState

impl Sync for Adjustment

impl Sync for DerefSource

impl Sync for SimplifyCfg

impl Sync for EdgeKind

impl Sync for AddRetag

impl Sync for Subtyper

impl Sync for CopyProp

impl Sync for BranchPair

impl Sync for CodeMapping

impl Sync for MCDCBranch

impl Sync for Hole

impl Sync for SpanFromMir

impl Sync for Covspan

impl Sync for CtfeLimit

impl Sync for Derefer

impl Sync for Candidates

impl Sync for WriteInfo

impl Sync for Marker

impl Sync for FnItemRef

impl Sync for GVN

impl Sync for VnIndex

impl Sync for Inline

impl Sync for Condition

impl Sync for EnumSizeOpt

impl Sync for LocalFinder

impl Sync for Candidate

impl Sync for RemoveZsts

impl Sync for RevealAll

impl Sync for SanityCheck

impl Sync for UsedLocals

impl Sync for SsaLocals

impl Sync for Validator

impl<'a> Sync for SuspendCheckData<'a>

impl<'a> Sync for CountersBuilder<'a>

impl<'a> Sync for CoverageSuccessors<'a>

impl<'a> Sync for UnknownPassName<'a>

impl<'a> Sync for ConditionSet<'a>

impl<'a, 'b, 'tcx> !Sync for OperandCollector<'a, 'b, 'tcx>

impl<'a, 'tcx> !Sync for SubTypeChecker<'a, 'tcx>

impl<'a, 'tcx> !Sync for PointerFinder<'a, 'tcx>

impl<'a, 'tcx> !Sync for ConstMutationChecker<'a, 'tcx>

impl<'a, 'tcx> !Sync for PackedRefChecker<'a, 'tcx>

impl<'a, 'tcx> !Sync for UndefinedTransmutesChecker<'a, 'tcx>

impl<'a, 'tcx> !Sync for Replacer<'a, 'tcx>

impl<'a, 'tcx> !Sync for Collector<'a, 'tcx>

impl<'a, 'tcx> !Sync for ConstAnalysis<'a, 'tcx>

impl<'a, 'tcx> !Sync for DerefChecker<'a, 'tcx>

impl<'a, 'tcx> !Sync for ElaborateBoxDerefVisitor<'a, 'tcx>

impl<'a, 'tcx> !Sync for ElaborateDropsCtxt<'a, 'tcx>

impl<'a, 'tcx> !Sync for InitializationData<'a, 'tcx>

impl<'a, 'tcx> !Sync for MustNotSupend<'a, 'tcx>

impl<'a, 'tcx> !Sync for FunctionItemRefChecker<'a, 'tcx>

impl<'a, 'tcx> !Sync for Integrator<'a, 'tcx>

impl<'a, 'tcx> !Sync for InstSimplifyContext<'a, 'tcx>

impl<'a, 'tcx> !Sync for TOFinder<'a, 'tcx>

impl<'a, 'tcx> !Sync for Lint<'a, 'tcx>

impl<'a, 'tcx> !Sync for MentionedItemsVisitor<'a, 'tcx>

impl<'a, 'tcx> !Sync for Collector<'a, 'tcx>

impl<'a, 'tcx> !Sync for Promoter<'a, 'tcx>

impl<'a, 'tcx> !Sync for Validator<'a, 'tcx>

impl<'a, 'tcx> !Sync for Replacer<'a, 'tcx>

impl<'a, 'tcx> !Sync for DropShimElaborator<'a, 'tcx>

impl<'a, 'tcx> !Sync for CfgChecker<'a, 'tcx>

impl<'a, 'tcx> !Sync for TypeChecker<'a, 'tcx>

impl<'a, 'tcx> Sync for ExpectedTransformKind<'a, 'tcx>

impl<'a, 'tcx> Sync for AssignedValue<'a, 'tcx>

impl<'a, 'tcx> Sync for StorageConflictVisitor<'a, 'tcx>

impl<'a, 'tcx> Sync for CoverageRelevantSubgraph<'a, 'tcx>

impl<'a, 'tcx> Sync for BasicBlockHashable<'a, 'tcx>

impl<'a, 'tcx> Sync for FilterInformation<'a, 'tcx>

impl<'a, 'tcx> Sync for FindAssignments<'a, 'tcx>

impl<'a, 'tcx> Sync for CfgSimplifier<'a, 'tcx>

impl<'a, 'tcx> Sync for OptimizationFinder<'a, 'tcx>

impl<'a, 'tcx> Sync for SsaVisitor<'a, 'tcx>

impl<'b, 'tcx> !Sync for CostChecker<'b, 'tcx>

impl<'b, 'tcx> !Sync for CostChecker<'b, 'tcx>

impl<'body, 'tcx> !Sync for VnState<'body, 'tcx>

impl<'mir, 'tcx> !Sync for ConstPropagator<'mir, 'tcx>

impl<'tcx> !Sync for MakeByMoveBody<'tcx>

impl<'tcx> !Sync for RenameLocalVisitor<'tcx>

impl<'tcx> !Sync for SelfArgVisitor<'tcx>

impl<'tcx> !Sync for TransformVisitor<'tcx>

impl<'tcx> !Sync for Patch<'tcx>

impl<'tcx> !Sync for OptApplier<'tcx>

impl<'tcx> !Sync for Merger<'tcx>

impl<'tcx> !Sync for StorageRemover<'tcx>

impl<'tcx> !Sync for Inliner<'tcx>

impl<'tcx> !Sync for RenameToReturnPlace<'tcx>

impl<'tcx> !Sync for BasicBlockUpdater<'tcx>

impl<'tcx> !Sync for LocalUpdater<'tcx>

impl<'tcx> !Sync for PromoteTemps<'tcx>

impl<'tcx> !Sync for Replacer<'tcx>

impl<'tcx> !Sync for RevealAllVisitor<'tcx>

impl<'tcx> !Sync for AsyncDestructorCtorShimBuilder<'tcx>

impl<'tcx> !Sync for CloneShimBuilder<'tcx>

impl<'tcx> !Sync for LocalUpdater<'tcx>

impl<'tcx> !Sync for LocalReplacer<'tcx>

impl<'tcx> Sync for AggregateTy<'tcx>

impl<'tcx> Sync for Value<'tcx>

impl<'tcx> Sync for Value<'tcx>

impl<'tcx> Sync for Value<'tcx>

impl<'tcx> Sync for CallKind<'tcx>

impl<'tcx> Sync for SuspensionPoint<'tcx>

impl<'tcx> Sync for OptimizationData<'tcx>

impl<'tcx> Sync for CallSite<'tcx>

impl<'tcx> Sync for RequiredConstsVisitor<'tcx>

impl<'tcx> Sync for OptimizationInfo<'tcx>

impl<'tcx> Sync for ReplacementMap<'tcx>

impl<'tcx, 'll> !Sync for ReplacementVisitor<'tcx, 'll>

impl<P> Sync for AssertLint<P>
where P: Sync,

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

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

impl<'a, 'tcx> !Sync for MirUsedCollector<'a, 'tcx>

impl<'a, 'tcx> !Sync for RootCollector<'a, 'tcx>

impl<'a, 'tcx> !Sync for PartitioningCx<'a, 'tcx>

impl<'a, 'tcx> !Sync for MarkUsedGenericParams<'a, 'tcx>

impl<'tcx> !Sync for SharedState<'tcx>

impl<'tcx> !Sync for MoveCheckVisitor<'tcx>

impl<'tcx> Sync for UsageMap<'tcx>

impl<'tcx> Sync for PlacedMonoItems<'tcx>

impl Sync for Conflict

impl Sync for InCrate

impl Sync for HasChanged

impl<'a, D, I> Sync for Canonicalizer<'a, D, I>
where D: Sync, <I as Interner>::GenericArg: Sync, <I as Interner>::Ty: Sync, <I as Interner>::PlaceholderTy: Sync, <I as Interner>::PlaceholderRegion: Sync, <I as Interner>::PlaceholderConst: Sync,

impl<'a, D, I> Sync for EagerResolver<'a, D, I>
where D: Sync, <I as Interner>::Ty: Sync,

impl<'a, D, I> Sync for ReplaceProjectionWith<'a, D, I>
where <I as Interner>::ParamEnv: Sync, <I as Interner>::CanonicalVars: Sync, <I as Interner>::PredefinedOpaques: Sync, D: Sync, <I as Interner>::GenericArgs: Sync, <I as Interner>::DefId: Sync, <I as Interner>::Predicate: Sync, <I as Interner>::BoundVarKinds: Sync, <I as Interner>::Term: Sync, <I as Interner>::DefiningOpaqueTypes: Sync, <I as Interner>::GenericArg: Sync, <I as Interner>::ExternalConstraints: Sync,

impl<'a, D, I> Sync for EvalCtxt<'a, D, I>
where <I as Interner>::CanonicalVars: Sync, <I as Interner>::PredefinedOpaques: Sync, D: Sync, <I as Interner>::GenericArgs: Sync, <I as Interner>::ParamEnv: Sync, <I as Interner>::Term: Sync, <I as Interner>::Predicate: Sync, <I as Interner>::DefId: Sync, <I as Interner>::DefiningOpaqueTypes: Sync, <I as Interner>::GenericArg: Sync, <I as Interner>::ExternalConstraints: Sync,

impl<'a, Infcx, I, F> Sync for OrphanChecker<'a, Infcx, I, F>
where F: Sync, Infcx: Sync, <I as Interner>::Ty: Sync,

impl<'me, 'a, D, I> Sync for ReplaceAliasWithInfer<'me, 'a, D, I>
where <I as Interner>::ParamEnv: Sync, <I as Interner>::CanonicalVars: Sync, <I as Interner>::PredefinedOpaques: Sync, D: Sync, <I as Interner>::GenericArgs: Sync, <I as Interner>::Ty: Sync, <I as Interner>::Term: Sync, <I as Interner>::Predicate: Sync, <I as Interner>::DefId: Sync, <I as Interner>::DefiningOpaqueTypes: Sync, <I as Interner>::GenericArg: Sync, <I as Interner>::ExternalConstraints: Sync,

impl<'me, 'a, D, I, F> Sync for TraitProbeCtxt<'me, 'a, D, I, F>
where F: Sync, <I as Interner>::DefId: Sync, <I as Interner>::CanonicalVars: Sync, <I as Interner>::PredefinedOpaques: Sync, D: Sync, <I as Interner>::GenericArgs: Sync, <I as Interner>::ExternalConstraints: Sync, <I as Interner>::ParamEnv: Sync, <I as Interner>::Term: Sync, <I as Interner>::Predicate: Sync, <I as Interner>::DefiningOpaqueTypes: Sync, <I as Interner>::GenericArg: Sync,

impl<'me, 'a, D, I, F, T> Sync for ProbeCtxt<'me, 'a, D, I, F, T>
where F: Sync, T: Sync, <I as Interner>::CanonicalVars: Sync, <I as Interner>::PredefinedOpaques: Sync, D: Sync, <I as Interner>::GenericArgs: Sync, <I as Interner>::ParamEnv: Sync, <I as Interner>::Term: Sync, <I as Interner>::Predicate: Sync, <I as Interner>::DefId: Sync, <I as Interner>::DefiningOpaqueTypes: Sync, <I as Interner>::GenericArg: Sync, <I as Interner>::ExternalConstraints: Sync,

impl<D> Sync for SearchGraphDelegate<D>
where D: Sync,

impl<D, I> Sync for ProofTreeBuilder<D, I>
where D: Sync, <I as Interner>::ParamEnv: Sync, <I as Interner>::Predicate: Sync, <I as Interner>::CanonicalVars: Sync, <I as Interner>::DefiningOpaqueTypes: Sync, <I as Interner>::GenericArg: Sync, <I as Interner>::PredefinedOpaques: Sync, <I as Interner>::ExternalConstraints: Sync, <I as Interner>::DefId: Sync, <I as Interner>::GenericArgs: Sync,

impl<I> Sync for DebugSolver<I>
where <I as Interner>::ParamEnv: Sync, <I as Interner>::Predicate: Sync, <I as Interner>::CanonicalVars: Sync, <I as Interner>::DefiningOpaqueTypes: Sync, <I as Interner>::GenericArg: Sync, <I as Interner>::PredefinedOpaques: Sync, <I as Interner>::ExternalConstraints: Sync, <I as Interner>::DefId: Sync, <I as Interner>::GenericArgs: Sync,

impl<I> Sync for WipProbeStep<I>
where <I as Interner>::CanonicalVars: Sync, <I as Interner>::GenericArgs: Sync, <I as Interner>::ParamEnv: Sync, <I as Interner>::Predicate: Sync, <I as Interner>::DefId: Sync, <I as Interner>::ExternalConstraints: Sync,

impl<I> Sync for NotUniqueParam<I>
where <I as Interner>::GenericArg: Sync,

impl<I> Sync for Candidate<I>
where <I as Interner>::DefId: Sync, <I as Interner>::CanonicalVars: Sync, <I as Interner>::ExternalConstraints: Sync, <I as Interner>::GenericArgs: Sync,

impl<I> Sync for AsyncCallableRelevantTypes<I>
where <I as Interner>::Ty: Sync,

impl<I> Sync for NestedGoals<I>
where <I as Interner>::ParamEnv: Sync, <I as Interner>::Term: Sync, <I as Interner>::Predicate: Sync, <I as Interner>::GenericArgs: Sync, <I as Interner>::DefId: Sync,

impl<I> Sync for WipCanonicalGoalEvaluation<I>
where <I as Interner>::CanonicalVars: Sync, <I as Interner>::DefiningOpaqueTypes: Sync, <I as Interner>::PredefinedOpaques: Sync, <I as Interner>::ParamEnv: Sync, <I as Interner>::Predicate: Sync, <I as Interner>::ExternalConstraints: Sync, <I as Interner>::GenericArg: Sync, <I as Interner>::GenericArgs: Sync, <I as Interner>::DefId: Sync,

impl<I> Sync for WipCanonicalGoalEvaluationStep<I>
where <I as Interner>::GenericArg: Sync, <I as Interner>::CanonicalVars: Sync, <I as Interner>::DefId: Sync, <I as Interner>::GenericArgs: Sync, <I as Interner>::ExternalConstraints: Sync, <I as Interner>::ParamEnv: Sync, <I as Interner>::Predicate: Sync,

impl<I> Sync for WipGoalEvaluation<I>
where <I as Interner>::ParamEnv: Sync, <I as Interner>::Predicate: Sync, <I as Interner>::GenericArg: Sync, <I as Interner>::CanonicalVars: Sync, <I as Interner>::DefiningOpaqueTypes: Sync, <I as Interner>::PredefinedOpaques: Sync, <I as Interner>::ExternalConstraints: Sync, <I as Interner>::GenericArgs: Sync, <I as Interner>::DefId: Sync,

impl<I> Sync for WipProbe<I>
where <I as Interner>::CanonicalVars: Sync, <I as Interner>::DefId: Sync, <I as Interner>::GenericArgs: Sync, <I as Interner>::ExternalConstraints: Sync, <I as Interner>::ParamEnv: Sync, <I as Interner>::Predicate: Sync,

impl<I, E> Sync for OrphanCheckEarlyExit<I, E>
where E: Sync, <I as Interner>::Ty: Sync,

impl<I, T> Sync for OrphanCheckErr<I, T>
where T: Sync, <I as Interner>::Ty: Sync,

impl<I, T> Sync for UncoveredTyParams<I, T>
where T: Sync, <I as Interner>::Ty: Sync,

impl !Sync for FlatToken

impl !Sync for TokenType

impl !Sync for ExpectedSemi

impl !Sync for AttrWrapper

impl !Sync for CollectPos

impl !Sync for CaptureState

impl !Sync for SeqSep

impl !Sync for TokenCursor

impl Sync for IncOrDec

impl Sync for UnaryFixity

impl Sync for BlockMode

impl Sync for Capturing

impl Sync for Recovery

impl Sync for Trailing

impl Sync for EatOrResult

impl Sync for Expected

impl Sync for PathStyle

impl Sync for AllowPlus

impl Sync for AddBoxNew

impl Sync for AddParen

impl Sync for AsyncImpl

impl Sync for BadItemKind

impl Sync for BadTypePlus

impl Sync for BoxNotPat

impl Sync for ColonAsSemi

impl Sync for DotDotDot

impl Sync for DynAfterMut

impl Sync for EqFieldInit

impl Sync for InInTypo

impl Sync for RemoveLet

impl Sync for WrapType

impl Sync for MultiSugg

impl Sync for FnParseMode

impl Sync for NodeRange

impl Sync for ParserRange

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

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

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

impl<'a> Sync for IncorrectSemicolon<'a>

impl<'a> Sync for KwBadCase<'a>

impl<'a> Sync for MacroExpandsToAdtField<'a>

impl<'a> Sync for MacroRulesVisibility<'a>

impl<'a> Sync for NestedAdt<'a>

impl<'a> Sync for TransposeDynOrImpl<'a>

impl<'a> Sync for TransposeDynOrImplSugg<'a>

impl<'a> Sync for UnexpectedTokenAfterDot<'a>

impl<'a> Sync for UnknownPrefix<'a>

impl<'psess, 'src> !Sync for StringReader<'psess, 'src>

impl<'psess, 'src> !Sync for TokenTreesReader<'psess, 'src>

impl Sync for Alignment

impl Sync for DebugHex

impl Sync for ParseMode

impl Sync for Sign

impl Sync for Suggestion

impl Sync for InnerOffset

impl Sync for InnerSpan

impl Sync for ParseError

impl<'a> Sync for Count<'a>

impl<'a> Sync for Piece<'a>

impl<'a> Sync for Position<'a>

impl<'a> Sync for Argument<'a>

impl<'a> Sync for FormatSpec<'a>

impl<'a> Sync for Parser<'a>

impl Sync for ReportOn

impl Sync for MacroExport

impl Sync for UnusedNote

impl Sync for Duplicate

impl Sync for VarKind

impl Sync for Context

impl Sync for ItemKind

impl Sync for DeadItem

impl Sync for AbiNe

impl Sync for AbiOf

impl Sync for Cold

impl Sync for Confusables

impl Sync for Deprecated

impl Sync for DocInvalid

impl Sync for ExportName

impl Sync for ExternMain

impl Sync for LayoutAbi

impl Sync for LayoutAlign

impl Sync for LayoutOf

impl Sync for LayoutSize

impl Sync for Link

impl Sync for LinkOrdinal

impl Sync for LinkSection

impl Sync for Linkage

impl Sync for MacroUse

impl Sync for NoLink

impl Sync for NoMainErr

impl Sync for NoMangle

impl Sync for NoPatterns

impl Sync for PassByValue

impl Sync for ReprIdent

impl Sync for Unused

impl Sync for UsedStatic

impl Sync for Node

impl Sync for NodeStats

impl Sync for RWU

impl Sync for RWUTable

impl Sync for CaptureInfo

impl Sync for LiveNode

impl Sync for LocalInfo

impl Sync for Variable

impl Sync for BlockInfo

impl<'a> Sync for BreakInsideClosure<'a>

impl<'a> Sync for BreakInsideCoroutine<'a>

impl<'a> Sync for BreakNonLoop<'a>

impl<'a> Sync for DocAliasBadChar<'a>

impl<'a> Sync for DocAliasBadLocation<'a>

impl<'a> Sync for DocAliasEmpty<'a>

impl<'a> Sync for DocAliasNotAnAlias<'a>

impl<'a> Sync for DocAliasStartEnd<'a>

impl<'a> Sync for DocAttrNotCrateLevel<'a>

impl<'a> Sync for DocExpectStr<'a>

impl<'a> Sync for IgnoredAttr<'a>

impl<'a> Sync for IgnoredAttrWithMacro<'a>

impl<'a> Sync for IncorrectTarget<'a>

impl<'a> Sync for LinkName<'a>

impl<'a> Sync for MissingConstStabAttr<'a>

impl<'a> Sync for MissingStabilityAttr<'a>

impl<'a> Sync for OutsideLoop<'a>

impl<'a> Sync for UnlabeledInLabeledBlock<'a>

impl<'a> Sync for UselessAssignment<'a>

impl<'a, 'hir> !Sync for HirIdValidator<'a, 'hir>

impl<'a, 'tcx> !Sync for Liveness<'a, 'tcx>

impl<'a, 'tcx> !Sync for Annotator<'a, 'tcx>

impl<'a, 'tcx> !Sync for CaptureCollector<'a, 'tcx>

impl<'a, 'tcx> !Sync for WeakLangItemVisitor<'a, 'tcx>

impl<'ast, 'tcx> !Sync for LanguageItemCollector<'ast, 'tcx>

impl<'desc, 'tcx> Sync for UnreachableDueToUninhabited<'desc, 'tcx>

impl<'k> !Sync for StatCollector<'k>

impl<'tcx> !Sync for ItemLike<'tcx>

impl<'tcx> !Sync for CheckAttrVisitor<'tcx>

impl<'tcx> !Sync for CheckConstVisitor<'tcx>

impl<'tcx> !Sync for DeadVisitor<'tcx>

impl<'tcx> !Sync for MarkSymbolVisitor<'tcx>

impl<'tcx> !Sync for EntryContext<'tcx>

impl<'tcx> !Sync for UnwrapLayoutCx<'tcx>

impl<'tcx> !Sync for LibFeatureCollector<'tcx>

impl<'tcx> !Sync for IrMaps<'tcx>

impl<'tcx> !Sync for CheckLoopVisitor<'tcx>

impl<'tcx> !Sync for CheckNakedAsmInNakedFn<'tcx>

impl<'tcx> !Sync for CheckParameters<'tcx>

impl<'tcx> !Sync for ReachableContext<'tcx>

impl<'tcx> !Sync for CheckTraitImplStable<'tcx>

impl<'tcx> !Sync for Checker<'tcx>

impl<'tcx> !Sync for MissingStabilityAnnotations<'tcx>

impl<'tcx> Sync for MultipleDeadCodes<'tcx>

impl<'tcx> Sync for ParentInfo<'tcx>

impl<'tcx> Sync for CollectLitsVisitor<'tcx>

impl Sync for Presence

impl Sync for RangeEnd

impl Sync for SliceKind

impl Sync for IntRange

impl Sync for OpaqueId

impl Sync for Slice

impl Sync for GappedRange

impl Sync for Overlap

impl Sync for Uncovered

impl Sync for PatId

impl Sync for FieldPat

impl<'a, 'p, Cx> Sync for UsefulnessCtxt<'a, 'p, Cx>
where Cx: Sync, <Cx as PatCx>::Ty: Sync, <Cx as PatCx>::PatData: Sync, <Cx as PatCx>::VariantIdx: Sync, <Cx as PatCx>::StrLit: Sync,

impl<'a, Cx> Sync for PlaceCtxt<'a, Cx>
where Cx: Sync, <Cx as PatCx>::Ty: Sync,

impl<'p, 'tcx> !Sync for RustcPatCtxt<'p, 'tcx>

impl<'p, Cx> Sync for PatOrWild<'p, Cx>
where <Cx as PatCx>::Ty: Sync, <Cx as PatCx>::PatData: Sync, <Cx as PatCx>::VariantIdx: Sync, <Cx as PatCx>::StrLit: Sync,

impl<'p, Cx> Sync for Usefulness<'p, Cx>
where <Cx as PatCx>::Ty: Sync, <Cx as PatCx>::PatData: Sync, <Cx as PatCx>::VariantIdx: Sync, <Cx as PatCx>::StrLit: Sync,

impl<'p, Cx> Sync for PatternColumn<'p, Cx>
where <Cx as PatCx>::Ty: Sync, <Cx as PatCx>::PatData: Sync, <Cx as PatCx>::VariantIdx: Sync, <Cx as PatCx>::StrLit: Sync,

impl<'p, Cx> Sync for MatchArm<'p, Cx>
where <Cx as PatCx>::ArmData: Sync, <Cx as PatCx>::Ty: Sync, <Cx as PatCx>::PatData: Sync, <Cx as PatCx>::VariantIdx: Sync, <Cx as PatCx>::StrLit: Sync,

impl<'p, Cx> Sync for BranchPatUsefulness<'p, Cx>
where <Cx as PatCx>::Ty: Sync, <Cx as PatCx>::PatData: Sync, <Cx as PatCx>::VariantIdx: Sync, <Cx as PatCx>::StrLit: Sync,

impl<'p, Cx> Sync for Matrix<'p, Cx>
where <Cx as PatCx>::Ty: Sync, <Cx as PatCx>::PatData: Sync, <Cx as PatCx>::VariantIdx: Sync, <Cx as PatCx>::StrLit: Sync,

impl<'p, Cx> Sync for MatrixRow<'p, Cx>
where <Cx as PatCx>::Ty: Sync, <Cx as PatCx>::PatData: Sync, <Cx as PatCx>::VariantIdx: Sync, <Cx as PatCx>::StrLit: Sync,

impl<'p, Cx> Sync for PatStack<'p, Cx>
where <Cx as PatCx>::Ty: Sync, <Cx as PatCx>::PatData: Sync, <Cx as PatCx>::VariantIdx: Sync, <Cx as PatCx>::StrLit: Sync,

impl<'p, Cx> Sync for RedundancyExplanation<'p, Cx>
where <Cx as PatCx>::Ty: Sync, <Cx as PatCx>::PatData: Sync, <Cx as PatCx>::VariantIdx: Sync, <Cx as PatCx>::StrLit: Sync,

impl<'p, Cx> Sync for UsefulnessReport<'p, Cx>
where <Cx as PatCx>::Ty: Sync, <Cx as PatCx>::ArmData: Sync, <Cx as PatCx>::VariantIdx: Sync, <Cx as PatCx>::StrLit: Sync, <Cx as PatCx>::PatData: Sync,

impl<'tcx> Sync for EnumInfo<'tcx>

impl<'tcx> Sync for NonExhaustiveOmittedPattern<'tcx>

impl<'tcx> Sync for RevealedTy<'tcx>

impl<Cx> Sync for Constructor<Cx>
where <Cx as PatCx>::VariantIdx: Sync, <Cx as PatCx>::StrLit: Sync,

impl<Cx> Sync for ConstructorSet<Cx>

impl<Cx> Sync for SplitConstructorSet<Cx>
where <Cx as PatCx>::VariantIdx: Sync, <Cx as PatCx>::StrLit: Sync,

impl<Cx> Sync for DeconstructedPat<Cx>
where <Cx as PatCx>::Ty: Sync, <Cx as PatCx>::PatData: Sync, <Cx as PatCx>::VariantIdx: Sync, <Cx as PatCx>::StrLit: Sync,

impl<Cx> Sync for IndexedPat<Cx>
where <Cx as PatCx>::Ty: Sync, <Cx as PatCx>::PatData: Sync, <Cx as PatCx>::VariantIdx: Sync, <Cx as PatCx>::StrLit: Sync,

impl<Cx> Sync for WitnessPat<Cx>
where <Cx as PatCx>::Ty: Sync, <Cx as PatCx>::VariantIdx: Sync, <Cx as PatCx>::StrLit: Sync,

impl<Cx> Sync for PlaceInfo<Cx>
where <Cx as PatCx>::Ty: Sync,

impl<Cx> Sync for WitnessMatrix<Cx>
where <Cx as PatCx>::Ty: Sync, <Cx as PatCx>::VariantIdx: Sync, <Cx as PatCx>::StrLit: Sync,

impl<Cx> Sync for WitnessStack<Cx>
where <Cx as PatCx>::Ty: Sync, <Cx as PatCx>::VariantIdx: Sync, <Cx as PatCx>::StrLit: Sync,

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

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

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

impl<'a, 'tcx> !Sync for PrivateItemsInPublicInterfacesChecker<'a, 'tcx>

impl<'a, 'tcx> !Sync for ReachEverythingInTheInterfaceVisitor<'a, 'tcx>

impl<'a, 'tcx> !Sync for TestReachabilityVisitor<'a, 'tcx>

impl<'a, 'tcx, VL, const SHALLOW: bool> !Sync for FindMin<'a, 'tcx, VL, SHALLOW>

impl<'tcx> !Sync for EmbargoVisitor<'tcx>

impl<'tcx> !Sync for LazyDefPathStr<'tcx>

impl<'tcx> !Sync for NamePrivacyVisitor<'tcx>

impl<'tcx> !Sync for TypePrivacyVisitor<'tcx>

impl<'v, 'tcx, V> !Sync for DefIdVisitorSkeleton<'v, 'tcx, V>

impl<'a, 'tcx> !Sync for QueryKeyStringBuilder<'a, 'tcx>

impl<'tcx> !Sync for QueryCtxt<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx> Sync for QueryType<'tcx>

impl<'tcx, C, const ANON: bool, const DEPTH_LIMIT: bool, const FEEDABLE: bool> !Sync for DynamicConfig<'tcx, C, ANON, DEPTH_LIMIT, FEEDABLE>

impl !Sync for EdgeFilter

impl Sync for Alias

impl Sync for StackCount

impl Sync for QueryMode

impl Sync for QueryResult

impl Sync for DepKind

impl Sync for DepNode

impl Sync for EdgesVec

impl Sync for EdgeIndex

impl Sync for TaskDeps

impl Sync for WorkProduct

impl Sync for EdgeHeader

impl Sync for NodeInfo

impl Sync for Stat

impl Sync for Unpacked

impl Sync for Cycle

impl Sync for CycleStack

impl Sync for CycleUsage

impl Sync for Reentrant

impl Sync for QueryInfo

impl Sync for QueryJob

impl Sync for QueryJobId

impl Sync for QueryLatch

impl Sync for QueryWaiter

impl Sync for CycleError

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

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

impl<'a> Sync for MarkFrame<'a>

impl<'tcx, K> !Sync for JobOwner<'tcx, K>

impl<D> !Sync for CurrentDepGraph<D>

impl<D> !Sync for DepGraph<D>

impl<D> !Sync for DepGraphData<D>

impl<D> !Sync for GraphEncoder<D>

impl<D> Sync for EncoderState<D>
where D: Sync,

impl<D> Sync for SerializedNodeHeader<D>
where D: Sync,

impl<K> !Sync for QueryState<K>

impl<K, V> !Sync for DefaultCache<K, V>

impl<K, V> !Sync for VecCache<K, V>

impl<Key, Value> !Sync for Cache<Key, Value>

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

impl<Tcx> Sync for DepKindStruct<Tcx>

impl<V> !Sync for DefIdCache<V>

impl<V> Sync for SingleCache<V>
where V: Sync + Send,

impl !Sync for UnusedImport

impl !Sync for DeriveData

impl !Sync for MacroData

impl Sync for DiagMode

impl Sync for FoundUse

impl Sync for Instead

impl Sync for Determinacy

impl Sync for ModuleKind

impl Sync for Used

impl Sync for Weak

impl Sync for DefinedHere

impl Sync for ImportIdent

impl Sync for UsePrelude

impl Sync for PatBoundCtx

impl Sync for ModuleOnly

impl Sync for BaseError

impl Sync for BindingInfo

impl Sync for LifetimeRib

impl Sync for DocFragment

impl Sync for BindingKey

impl Sync for Finalize

impl Sync for Segment

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

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

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

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

impl<'a> Sync for AddAsNonDerive<'a>

impl<'a> Sync for IdentInScopeButItIsDesc<'a>

impl<'a> Sync for ImportsCannotReferTo<'a>

impl<'a> Sync for IsPrivate<'a>

impl<'a> Sync for MacroExpectedFound<'a>

impl<'a, 'ast, 'ra, 'tcx> !Sync for LateResolutionVisitor<'a, 'ast, 'ra, 'tcx>

impl<'a, 'ra, 'tcx> !Sync for BuildReducedGraphVisitor<'a, 'ra, 'tcx>

impl<'a, 'ra, 'tcx> !Sync for UnusedImportCheckVisitor<'a, 'ra, 'tcx>

impl<'a, 'ra, 'tcx> !Sync for DefCollector<'a, 'ra, 'tcx>

impl<'a, 'ra, 'tcx> !Sync for EffectiveVisibilitiesVisitor<'a, 'ra, 'tcx>

impl<'a, 'ra, 'tcx> !Sync for ItemInfoCollector<'a, 'ra, 'tcx>

impl<'ast> !Sync for LifetimeFinder<'ast>

impl<'ast> !Sync for DiagMetadata<'ast>

impl<'ra> !Sync for ParentId<'ra>

impl<'ra> !Sync for LexicalScopeBinding<'ra>

impl<'ra> !Sync for ModuleOrUniformRoot<'ra>

impl<'ra> !Sync for NameBindingKind<'ra>

impl<'ra> !Sync for PathResult<'ra>

impl<'ra> !Sync for ResolutionError<'ra>

impl<'ra> !Sync for Scope<'ra>

impl<'ra> !Sync for ScopeSet<'ra>

impl<'ra> !Sync for ImportKind<'ra>

impl<'ra> !Sync for RibKind<'ra>

impl<'ra> !Sync for MacroRulesScope<'ra>

impl<'ra> !Sync for ImportData<'ra>

impl<'ra> !Sync for NameResolution<'ra>

impl<'ra> !Sync for UnnecessaryQualification<'ra>

impl<'ra> !Sync for MacroRulesBinding<'ra>

impl<'ra> !Sync for AmbiguityError<'ra>

impl<'ra> !Sync for ExternPreludeEntry<'ra>

impl<'ra> !Sync for Module<'ra>

impl<'ra> !Sync for ModuleData<'ra>

impl<'ra> !Sync for NameBindingData<'ra>

impl<'ra> !Sync for ParentScope<'ra>

impl<'ra> !Sync for PrivacyError<'ra>

impl<'ra> !Sync for ResolverArenas<'ra>

impl<'ra, 'tcx> !Sync for Resolver<'ra, 'tcx>

impl<'ra, R = Res<NodeId>> !Sync for Rib<'ra, R>

impl Sync for TyQ

impl<'tcx> !Sync for TransformTy<'tcx>

impl<'tcx> Sync for DictKey<'tcx>

impl Sync for FileEncoder

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

impl !Sync for CodeStats

impl !Sync for NativeLib

impl !Sync for Untracked

impl !Sync for GatedSpans

impl !Sync for ParseSess

impl !Sync for Session

impl Sync for FieldKind

impl Sync for SizeKind

impl Sync for CFGuard

impl Sync for CrateType

impl Sync for DebugInfo

impl Sync for EntryFnType

impl Sync for FmtDebug

impl Sync for Input

impl Sync for Lto

impl Sync for LtoCli

impl Sync for OomStrategy

impl Sync for OptLevel

impl Sync for OptionKind

impl Sync for OutFileName

impl Sync for OutputType

impl Sync for PAuthKey

impl Sync for Passes

impl Sync for Polonius

impl Sync for PpHirMode

impl Sync for PpMode

impl Sync for PrintKind

impl Sync for Strip

impl Sync for PathKind

impl Sync for FieldInfo

impl Sync for VariantInfo

impl Sync for CheckCfg

impl Sync for ExternEntry

impl Sync for Externs

impl Sync for JsonConfig

impl Sync for Options

impl Sync for OutputTypes

impl Sync for PacRet

impl Sync for CrateSource

impl Sync for DllImport

impl Sync for ExternCrate

impl Sync for SearchPath

impl Sync for CompilerIO

impl Sync for Limit

impl Sync for Limits

impl Sync for NativeLib

impl<'a> Sync for CrateNameInvalid<'a>

impl<'a> Sync for FileIsNotWriteable<'a>

impl<'a> Sync for FileWriteFail<'a>

impl<'a> Sync for InvalidLiteralSuffix<'a>

impl<'a> Sync for FileSearch<'a>

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

impl<'tcx> !Sync for BodyBuilder<'tcx>

impl<'tcx> !Sync for TablesWrapper<'tcx>

impl<'tcx> !Sync for Tables<'tcx>

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

impl !Sync for CacheEntry

impl !Sync for SourceMap

impl !Sync for FileLines

impl !Sync for Loc

impl !Sync for SourceFile

impl !Sync for Interner

impl Sync for Edition

impl Sync for FileName

impl Sync for AstPass

impl Sync for ExpnKind

impl Sync for MacroKind

impl Sync for CrateNum

impl Sync for DefId

impl Sync for DefIndex

impl Sync for DefPathHash

impl Sync for LocalDefId

impl Sync for ModDefId

impl Sync for FatalError

impl Sync for ExpnData

impl Sync for ExpnHash

impl Sync for ExpnId

impl Sync for ExpnIndex

impl Sync for HygieneData

impl Sync for LocalExpnId

impl Sync for InlineCtxt

impl Sync for Interned

impl Sync for Span

impl Sync for AttrId

impl Sync for BytePos

impl Sync for CharPos

impl Sync for InnerSpan

impl Sync for LineInfo

impl Sync for SpanData

impl Sync for AllKeywords

impl Sync for Ident

impl Sync for Symbol

impl Sync for SymbolIndex

impl<'a> Sync for FileNameDisplay<'a>

impl<'sm> !Sync for CachingSourceMapView<'sm>

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

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

impl Sync for Kind

impl Sync for TestOutput

impl Sync for SymbolPath

impl Sync for BinderLevel

impl<'tcx> !Sync for SymbolPrinter<'tcx>

impl<'tcx> !Sync for SymbolNamesTest<'tcx>

impl<'tcx> !Sync for SymbolMangler<'tcx>

impl Sync for AbiKind

impl Sync for Conv

impl Sync for PassMode

impl Sync for FloatConv

impl Sync for RegPassKind

impl Sync for ABI

impl Sync for FloatConv

impl Sync for RegPassKind

impl Sync for Flavor

impl Sync for Class

impl Sync for Arch

impl Sync for TargetAbi

impl Sync for Cc

impl Sync for CodeModel

impl Sync for Lld

impl Sync for LldFlavor

impl Sync for RelocModel

impl Sync for RelroLevel

impl Sync for TargetTuple

impl Sync for TlsModel

impl Sync for WasmCAbi

impl Sync for Stability

impl Sync for Sdata

impl Sync for CastTarget

impl Sync for Uniform

impl Sync for X86Options

impl Sync for Memory

impl Sync for Target

impl Sync for X86Abi

impl<'a, Ty> Sync for ArgAbi<'a, Ty>
where Ty: Sync,

impl<'a, Ty> Sync for FnAbi<'a, Ty>
where Ty: Sync,

impl Sync for FailureCode

impl Sync for TyCategory

impl Sync for ArgKind

impl Sync for DefIdOrName

impl Sync for PrefixKind

impl Sync for SuffixKind

impl Sync for DropVictim

impl Sync for Elaborate

impl Sync for SubId

impl Sync for FnUniqTypes

impl Sync for Select

impl Sync for InProgress

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

impl<'a> Sync for RegionOriginNote<'a>

impl<'a> Sync for SourceKindSubdiag<'a>

impl<'a> Sync for SuggestAccessingField<'a>

impl<'a> Sync for HirTraitObjectVisitor<'a>

impl<'a> Sync for ReplaceImplTraitVisitor<'a>

impl<'a> Sync for DescriptionCtx<'a>

impl<'a> Sync for RegionExplanation<'a>

impl<'a> Sync for AmbiguousImpl<'a>

impl<'a> Sync for AmbiguousReturn<'a>

impl<'a> Sync for AnnotationRequired<'a>

impl<'a> Sync for DumpVTableEntries<'a>

impl<'a> Sync for FulfillReqLifetime<'a>

impl<'a> Sync for InferenceBadError<'a>

impl<'a> Sync for LfBoundNotSatisfied<'a>

impl<'a> Sync for OutlivesBound<'a>

impl<'a> Sync for OutlivesContent<'a>

impl<'a> Sync for RefLongerThanData<'a>

impl<'a, 'b, 'tcx> !Sync for AssocTypeNormalizer<'a, 'b, 'tcx>

impl<'a, 'tcx> !Sync for FindInferSourceVisitor<'a, 'tcx>

impl<'a, 'tcx> !Sync for SameTypeModuloInfer<'a, 'tcx>

impl<'a, 'tcx> !Sync for TypeErrCtxt<'a, 'tcx>

impl<'a, 'tcx> !Sync for InspectCandidate<'a, 'tcx>

impl<'a, 'tcx> !Sync for InspectGoal<'a, 'tcx>

impl<'a, 'tcx> !Sync for DeeplyNormalizeForDiagnosticsFolder<'a, 'tcx>

impl<'a, 'tcx> !Sync for FulfillProcessor<'a, 'tcx>

impl<'a, 'tcx> !Sync for QueryNormalizer<'a, 'tcx>

impl<'a, 'tcx> !Sync for BoundVarReplacer<'a, 'tcx>

impl<'a, 'tcx> !Sync for PlaceholderReplacer<'a, 'tcx>

impl<'a, 'tcx> !Sync for WfPredicates<'a, 'tcx>

impl<'a, 'tcx> Sync for CoroutineData<'a, 'tcx>

impl<'a, 'tcx> Sync for AmbiguityCausesVisitor<'a, 'tcx>

impl<'a, 'tcx, E = ScrubbedTraitError<'tcx>> !Sync for ObligationCtxt<'a, 'tcx, E>

impl<'cx> Sync for AutoTraitInfo<'cx>

impl<'cx, 'tcx> !Sync for NiceRegionError<'cx, 'tcx>

impl<'cx, 'tcx> !Sync for SelectionContext<'cx, 'tcx>

impl<'hir> !Sync for FindExprBySpan<'hir>

impl<'me, 'tcx, E> !Sync for NormalizationFolder<'me, 'tcx, E>

impl<'o, 'tcx> !Sync for TraitObligationStackList<'o, 'tcx>

impl<'prev, 'tcx> !Sync for TraitObligationStack<'prev, 'tcx>

impl<'tcx> !Sync for ActualImplExplNotes<'tcx>

impl<'tcx> !Sync for TyOrSig<'tcx>

impl<'tcx> !Sync for ClosureEraser<'tcx>

impl<'tcx> !Sync for FindNestedTypeVisitor<'tcx>

impl<'tcx> !Sync for TyPathVisitor<'tcx>

impl<'tcx> !Sync for TypeParamSpanVisitor<'tcx>

impl<'tcx> !Sync for ReplaceImplTraitFolder<'tcx>

impl<'tcx> !Sync for TraitPlaceholderMismatch<'tcx>

impl<'tcx> !Sync for SolverDelegate<'tcx>

impl<'tcx> !Sync for AutoTraitFinder<'tcx>

impl<'tcx> !Sync for EraseEscapingBoundRegions<'tcx>

impl<'tcx> !Sync for IllegalSelfTypeVisitor<'tcx>

impl<'tcx> !Sync for MatchAgainstFreshVars<'tcx>

impl<'tcx> !Sync for ProvisionalEvaluationCache<'tcx>

impl<'tcx> !Sync for TraitAliasExpander<'tcx>

impl<'tcx> Sync for InferSourceKind<'tcx>

impl<'tcx> Sync for OverflowCause<'tcx>

impl<'tcx> Sync for ChildMode<'tcx>

impl<'tcx> Sync for NextSolverError<'tcx>

impl<'tcx> Sync for RegionTarget<'tcx>

impl<'tcx> Sync for FulfillmentErrorCode<'tcx>

impl<'tcx> Sync for CopyImplementationError<'tcx>

impl<'tcx> Sync for InfringingFieldsReason<'tcx>

impl<'tcx> Sync for ProjectAndUnifyResult<'tcx>

impl<'tcx> Sync for Projected<'tcx>

impl<'tcx> Sync for ProjectionCandidate<'tcx>

impl<'tcx> Sync for ProjectionCandidateSet<'tcx>

impl<'tcx> Sync for ProjectionError<'tcx>

impl<'tcx> Sync for BuiltinImplConditions<'tcx>

impl<'tcx> Sync for IntercrateAmbiguityCause<'tcx>

impl<'tcx> Sync for Inserted<'tcx>

impl<'tcx> Sync for VtblSegment<'tcx>

impl<'tcx> Sync for InferSource<'tcx>

impl<'tcx> Sync for InsertableGenericArgs<'tcx>

impl<'tcx> Sync for AnonymousParamInfo<'tcx>

impl<'tcx> Sync for ObligationCauseAsDiagArg<'tcx>

impl<'tcx> Sync for ImplCandidate<'tcx>

impl<'tcx> Sync for NegativePositiveConflict<'tcx>

impl<'tcx> Sync for OpaqueCapturesLifetime<'tcx>

impl<'tcx> Sync for BestObligation<'tcx>

impl<'tcx> Sync for ObligationStorage<'tcx>

impl<'tcx> Sync for NormalizesToTermHack<'tcx>

impl<'tcx> Sync for RegionDeps<'tcx>

impl<'tcx> Sync for OverlapResult<'tcx>

impl<'tcx> Sync for OldSolverError<'tcx>

impl<'tcx> Sync for PendingPredicateObligation<'tcx>

impl<'tcx> Sync for Progress<'tcx>

impl<'tcx> Sync for EvaluatedCandidate<'tcx>

impl<'tcx> Sync for SelectionCandidateSet<'tcx>

impl<'tcx> Sync for FutureCompatOverlapError<'tcx>

impl<'tcx> Sync for OverlapError<'tcx>

impl<'tcx> Sync for FulfillmentError<'tcx>

impl<'tcx> Sync for TraitAliasExpansionInfo<'tcx>

impl<'tcx, E> !Sync for FulfillmentContext<'tcx, E>

impl<'tcx, E> Sync for FulfillmentCtxt<'tcx, E>
where E: Sync,

impl<'tcx, Op> Sync for TypeOpOutput<'tcx, Op>
where <Op as TypeOp<'tcx>>::Output: Sync, <Op as TypeOp<'tcx>>::ErrorInfo: Sync,

impl<'tcx, T> !Sync for Highlighted<'tcx, T>

impl<'v> Sync for ReturnsVisitor<'v>

impl<'v> Sync for SelfVisitor<'v>

impl<A> Sync for AutoTraitResult<A>
where A: Sync,

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

impl<I, J> Sync for PotentialSiblings<I, J>
where I: Sync, J: Sync,

impl Sync for Byte

impl Sync for Err

impl Sync for Quantifier

impl Sync for State

impl Sync for State

impl Sync for Uninhabited

impl Sync for Assume

impl<'cx, 'tcx> !Sync for TransmuteTypeEnv<'cx, 'tcx>

impl<'tcx> Sync for Def<'tcx>

impl<'tcx> Sync for Ref<'tcx>

impl<'tcx> Sync for Types<'tcx>

impl<D, R> Sync for Tree<D, R>
where D: Sync, R: Sync,

impl<L, C> Sync for MaybeTransmutableQuery<L, C>
where L: Sync, C: Sync,

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

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

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

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

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

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

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

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

impl Sync for DtorType

impl<'a, 'tcx> !Sync for ImplTraitInTraitFinder<'a, 'tcx>

impl<'a, 'tcx> Sync for IsThirPolymorphic<'a, 'tcx>

impl<'tcx> !Sync for OpaqueTypeCollector<'tcx>

impl<'tcx> Sync for DuplicateArg<'tcx>

impl<'tcx> Sync for MultipleArrayFieldsSimdType<'tcx>

impl<'tcx> Sync for NeedsDropOverflow<'tcx>

impl<'tcx> Sync for NonPrimitiveSimdType<'tcx>

impl<'tcx> Sync for NotParam<'tcx>

impl<'tcx> Sync for OversizedSimdType<'tcx>

impl<'tcx> Sync for ZeroLengthSimdType<'tcx>

impl<'tcx, F> !Sync for NeedsDropTypes<'tcx, F>

impl Sync for InferConst

impl Sync for Filter

impl Sync for ClosureKind

impl Sync for Variance

impl Sync for TreatParams

impl Sync for PathKind

impl Sync for UsageKind

impl Sync for Certainty

impl Sync for GoalSource

impl Sync for MaybeCause

impl Sync for Reveal

impl Sync for AliasTyKind

impl Sync for DynKind

impl Sync for FloatTy

impl Sync for InferTy

impl Sync for IntTy

impl Sync for IntVarValue

impl Sync for UintTy

impl Sync for ConstVid

impl Sync for TypeFlags

impl Sync for RegionVid

impl Sync for CycleHeads

impl Sync for StackDepth

impl Sync for NoSolution

impl Sync for BoundVar

impl Sync for FloatVid

impl Sync for IntVid

impl Sync for TyVid

impl Sync for FoundFlags

impl<'a, I> Sync for ArgFolder<'a, I>
where I: Sync, <I as Interner>::GenericArg: Sync,

impl<'a, I> Sync for OutlivesCollector<'a, I>
where I: Sync, <I as Interner>::Region: Sync, <I as Interner>::ParamTy: Sync, <I as Interner>::PlaceholderTy: Sync, <I as Interner>::GenericArgs: Sync, <I as Interner>::DefId: Sync, <I as Interner>::Ty: Sync,

impl<'a, I, Iter> Sync for IterInstantiatedCopied<'a, I, Iter>
where <Iter as IntoIterator>::IntoIter: Sync, I: Sync, <I as Interner>::GenericArg: Sync,

impl<'a, X> Sync for CacheData<'a, X>
where <X as Cx>::Result: Sync, <X as Cx>::Input: Sync,

impl<'infcx, Infcx, I> Sync for SolverRelating<'infcx, Infcx, I>
where <I as Interner>::ParamEnv: Sync, Infcx: Sync, <I as Interner>::Predicate: Sync, <I as Interner>::Ty: Sync,

impl<D, X> Sync for SearchGraph<D, X>
where D: Sync, <X as Cx>::Input: Sync, <X as Cx>::Result: Sync,

impl<DefId> Sync for SimplifiedType<DefId>
where DefId: Sync,

impl<I> Sync for TypeError<I>
where <I as Interner>::Region: Sync, <I as Interner>::BoundRegion: Sync, <I as Interner>::Ty: Sync, <I as Interner>::Const: Sync, <I as Interner>::DefId: Sync, <I as Interner>::Safety: Sync, <I as Interner>::Abi: Sync, <I as Interner>::BoundExistentialPredicates: Sync,

impl<I> Sync for GenericArgKind<I>
where <I as Interner>::Region: Sync, <I as Interner>::Ty: Sync, <I as Interner>::Const: Sync,

impl<I> Sync for TermKind<I>
where <I as Interner>::Ty: Sync, <I as Interner>::Const: Sync,

impl<I> Sync for TypingMode<I>

impl<I> Sync for Component<I>
where <I as Interner>::Region: Sync, <I as Interner>::ParamTy: Sync, <I as Interner>::PlaceholderTy: Sync, <I as Interner>::GenericArgs: Sync, <I as Interner>::DefId: Sync,

impl<I> Sync for ExistentialPredicate<I>
where <I as Interner>::DefId: Sync, <I as Interner>::GenericArgs: Sync, <I as Interner>::Term: Sync,

impl<I> Sync for ClauseKind<I>
where <I as Interner>::Const: Sync, <I as Interner>::Ty: Sync, <I as Interner>::GenericArg: Sync, <I as Interner>::Region: Sync, <I as Interner>::Term: Sync, <I as Interner>::DefId: Sync, <I as Interner>::GenericArgs: Sync,

impl<I> Sync for PredicateKind<I>
where <I as Interner>::DefId: Sync, <I as Interner>::Const: Sync, <I as Interner>::Term: Sync, <I as Interner>::Ty: Sync, <I as Interner>::GenericArg: Sync, <I as Interner>::Region: Sync, <I as Interner>::GenericArgs: Sync,

impl<I> Sync for VarianceDiagInfo<I>
where <I as Interner>::Ty: Sync,

impl<I> Sync for CandidateSource<I>
where <I as Interner>::DefId: Sync,

impl<I> Sync for ProbeKind<I>

impl<I> Sync for TyKind<I>

impl<I> Sync for ValidateBoundVars<I>
where <I as Interner>::BoundVarKinds: Sync, <I as Interner>::Ty: Sync,

impl<I> Sync for CanonicalVarValues<I>
where <I as Interner>::GenericArgs: Sync,

impl<I> Sync for UnevaluatedConst<I>
where <I as Interner>::DefId: Sync, <I as Interner>::GenericArgs: Sync,

impl<I> Sync for ClauseWithSupertraitSpan<I>
where <I as Interner>::Predicate: Sync, <I as Interner>::Span: Sync,

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

impl<I> Sync for OpaqueTypeKey<I>
where <I as Interner>::LocalDefId: Sync, <I as Interner>::GenericArgs: Sync,

impl<I> Sync for AliasTerm<I>
where <I as Interner>::GenericArgs: Sync, <I as Interner>::DefId: Sync,

impl<I> Sync for CoercePredicate<I>
where <I as Interner>::Ty: Sync,

impl<I> Sync for ExistentialProjection<I>
where <I as Interner>::DefId: Sync, <I as Interner>::GenericArgs: Sync, <I as Interner>::Term: Sync,

impl<I> Sync for ExistentialTraitRef<I>
where <I as Interner>::DefId: Sync, <I as Interner>::GenericArgs: Sync,

impl<I> Sync for HostEffectPredicate<I>
where <I as Interner>::DefId: Sync, <I as Interner>::GenericArgs: Sync,

impl<I> Sync for NormalizesTo<I>
where <I as Interner>::Term: Sync, <I as Interner>::GenericArgs: Sync, <I as Interner>::DefId: Sync,

impl<I> Sync for ProjectionPredicate<I>
where <I as Interner>::Term: Sync, <I as Interner>::GenericArgs: Sync, <I as Interner>::DefId: Sync,

impl<I> Sync for SubtypePredicate<I>
where <I as Interner>::Ty: Sync,

impl<I> Sync for TraitPredicate<I>
where <I as Interner>::DefId: Sync, <I as Interner>::GenericArgs: Sync,

impl<I> Sync for TraitRef<I>
where <I as Interner>::DefId: Sync, <I as Interner>::GenericArgs: Sync,

impl<I> Sync for Probe<I>

impl<I> Sync for ExternalConstraintsData<I>
where <I as Interner>::GenericArg: Sync, <I as Interner>::Region: Sync, <I as Interner>::Ty: Sync, <I as Interner>::LocalDefId: Sync, <I as Interner>::GenericArgs: Sync, <I as Interner>::ParamEnv: Sync, <I as Interner>::Predicate: Sync,

impl<I> Sync for NestedNormalizationGoals<I>
where <I as Interner>::ParamEnv: Sync, <I as Interner>::Predicate: Sync,

impl<I> Sync for PredefinedOpaquesData<I>
where <I as Interner>::Ty: Sync, <I as Interner>::LocalDefId: Sync, <I as Interner>::GenericArgs: Sync,

impl<I> Sync for Response<I>

impl<I> Sync for ClosureArgs<I>
where <I as Interner>::GenericArgs: Sync,

impl<I> Sync for ClosureArgsParts<I>
where <I as Interner>::GenericArgsSlice: Sync, <I as Interner>::Ty: Sync,

impl<I> Sync for CoroutineArgs<I>
where <I as Interner>::GenericArgs: Sync,

impl<I> Sync for CoroutineArgsParts<I>
where <I as Interner>::GenericArgsSlice: Sync, <I as Interner>::Ty: Sync,

impl<I> Sync for CoroutineClosureArgs<I>
where <I as Interner>::GenericArgs: Sync,

impl<I> Sync for CoroutineClosureSignature<I>
where <I as Interner>::Ty: Sync, <I as Interner>::Safety: Sync, <I as Interner>::Abi: Sync,

impl<I> Sync for FoldEscapingRegions<I>
where I: Sync, <I as Interner>::Region: Sync,

impl<I> Sync for GenSig<I>
where <I as Interner>::Ty: Sync,

impl<I> Sync for AliasTy<I>
where <I as Interner>::GenericArgs: Sync, <I as Interner>::DefId: Sync,

impl<I> Sync for FnHeader<I>
where <I as Interner>::Safety: Sync, <I as Interner>::Abi: Sync,

impl<I> Sync for FnSig<I>
where <I as Interner>::Tys: Sync, <I as Interner>::Safety: Sync, <I as Interner>::Abi: Sync,

impl<I> Sync for FnSigTys<I>
where <I as Interner>::Tys: Sync,

impl<I> Sync for TypeAndMut<I>
where <I as Interner>::Ty: Sync,

impl<I, A> Sync for OutlivesPredicate<I, A>
where A: Sync, <I as Interner>::Region: Sync,

impl<I, It> Sync for FilterToTraits<I, It>
where It: Sync, I: Sync,

impl<I, Iter, A> Sync for IterInstantiated<I, Iter, A>
where <Iter as IntoIterator>::IntoIter: Sync, I: Sync, A: Sync,

impl<I, O> Sync for Elaborator<I, O>
where I: Sync, O: Sync, <I as Interner>::BoundVarKinds: Sync, <I as Interner>::DefId: Sync, <I as Interner>::Const: Sync, <I as Interner>::Term: Sync, <I as Interner>::Ty: Sync, <I as Interner>::GenericArg: Sync, <I as Interner>::Region: Sync, <I as Interner>::GenericArgs: Sync,

impl<I, P> Sync for Goal<I, P>
where <I as Interner>::ParamEnv: Sync, P: Sync,

impl<I, P> Sync for QueryInput<I, P>
where <I as Interner>::PredefinedOpaques: Sync, <I as Interner>::ParamEnv: Sync, P: Sync,

impl<I, T> Sync for Binder<I, T>
where T: Sync, <I as Interner>::BoundVarKinds: Sync,

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

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

impl<I, T> Sync for State<I, T>
where T: Sync, <I as Interner>::GenericArgs: Sync,

impl<I, V> Sync for Canonical<I, V>
where V: Sync, <I as Interner>::CanonicalVars: Sync,

impl<I, V> Sync for CanonicalQueryInput<I, V>

impl<I, const INSTANTIATE_LHS_WITH_INFER: bool, const INSTANTIATE_RHS_WITH_INFER: bool> Sync for DeepRejectCtxt<I, INSTANTIATE_LHS_WITH_INFER, INSTANTIATE_RHS_WITH_INFER>
where I: Sync,

impl<Iter> Sync for IterIdentityCopied<Iter>
where <Iter as IntoIterator>::IntoIter: Sync,

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

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

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

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

impl<X> Sync for CacheEntry<X>
where <X as Cx>::Tracked<<X as Cx>::Result>: Sync, <X as Cx>::Input: Sync,

impl<X> Sync for GlobalCache<X>
where <X as Cx>::Input: Sync, <X as Cx>::Tracked<<X as Cx>::Result>: Sync,

impl<X> Sync for Success<X>
where <X as Cx>::Tracked<<X as Cx>::Result>: Sync, <X as Cx>::Input: Sync,

impl<X> Sync for WithOverflow<X>
where <X as Cx>::Tracked<<X as Cx>::Result>: Sync, <X as Cx>::Input: Sync,

impl<X> Sync for NestedGoals<X>
where <X as Cx>::Input: Sync,

impl<X> Sync for ProvisionalCacheEntry<X>
where <X as Cx>::Result: Sync, <X as Cx>::Input: Sync,

impl<X> Sync for StackEntry<X>
where <X as Cx>::Input: Sync, <X as Cx>::Result: Sync,

impl !Sync for ItemKind

impl !Sync for VariantKind

impl !Sync for Attributes

impl !Sync for Crate

impl !Sync for Enum

impl !Sync for Impl

impl !Sync for Item

impl !Sync for ItemInner

impl !Sync for Module

impl !Sync for Struct

impl !Sync for Trait

impl !Sync for TypeAlias

impl !Sync for Union

impl !Sync for Variant

impl !Sync for Cache

impl !Sync for Impl

impl !Sync for Hierarchy

impl Sync for Cfg

impl Sync for Format

impl Sync for GenericArg

impl Sync for GenericArgs

impl Sync for ImplKind

impl Sync for ImportKind

impl Sync for ItemId

impl Sync for Term

impl Sync for Type

impl Sync for EmitType

impl Sync for InputMode

impl Sync for DirState

impl Sync for TestFailure

impl Sync for AttrKind

impl Sync for ItemType

impl Sync for Ending

impl Sync for HrefError

impl Sync for Class

impl Sync for Tooltip

impl Sync for ErrorCodes

impl Sync for Ignore

impl Sync for ItemSection

impl Sync for RenderMode

impl Sync for Container

impl Sync for ModuleLike

impl Sync for LinkFromSrc

impl Sync for Res

impl Sync for Suggestion

impl Sync for UrlFragment

impl Sync for Condition

impl Sync for Argument

impl Sync for Arguments

impl Sync for Constant

impl Sync for FnDecl

impl Sync for Function

impl Sync for Generics

impl Sync for Import

impl Sync for ItemLink

impl Sync for Lifetime

impl Sync for Macro

impl Sync for Path

impl Sync for PathSegment

impl Sync for PolyTrait

impl Sync for ProcMacro

impl Sync for QPathData

impl Sync for Span

impl Sync for Static

impl Sync for TraitAlias

impl Sync for Options

impl Sync for PathToParts

impl Sync for ShouldMerge

impl Sync for DocFS

impl Sync for SourceInfo

impl Sync for MdCollector

impl Sync for Error

impl Sync for Buffer

impl Sync for Indent

impl Sync for Decorations

impl Sync for Layout

impl Sync for IdMap

impl Sync for Indices

impl Sync for LangString

impl Sync for MdRelLine

impl Sync for Playground

impl Sync for EscapedJson

impl Sync for OrderedJson

impl Sync for ImplString

impl Sync for Error

impl Sync for Html

impl Sync for Js

impl Sync for Offset

impl Sync for AllTypes

impl Sync for IndexItem

impl Sync for ItemEntry

impl Sync for ItemInfo

impl Sync for RenderType

impl Sync for StylePath

impl Sync for AllCrates

impl Sync for CrateInfo

impl Sync for CratesIndex

impl Sync for Implementor

impl Sync for SearchIndex

impl Sync for Sources

impl Sync for TraitAlias

impl Sync for TypeAlias

impl Sync for StaticFile

impl Sync for StaticFiles

impl Sync for Toc

impl Sync for TocBuilder

impl Sync for TocEntry

impl Sync for FullItemId

impl Sync for ItemCount

impl Sync for Tests

impl Sync for Buffer

impl Sync for LinkData

impl Sync for Element

impl Sync for Pass

impl Sync for CallData

impl Sync for SyntaxRange

impl Sync for CssPath

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

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

impl<'a> Sync for Highlight<'a>

impl<'a> Sync for LangStringToken<'a>

impl<'a> Sync for Line<'a>

impl<'a> Sync for AssocItemLink<'a>

impl<'a> Sync for AssocItemRender<'a>

impl<'a> Sync for SourceContext<'a>

impl<'a> Sync for ResolutionFailure<'a>

impl<'a> Sync for Display<'a>

impl<'a> Sync for Escape<'a>

impl<'a> Sync for EscapeBodyText<'a>

impl<'a> Sync for EscapeBodyTextWithWbr<'a>

impl<'a> Sync for PeekIter<'a>

impl<'a> Sync for TokenIter<'a>

impl<'a> Sync for Page<'a>

impl<'a> Sync for PageLayout<'a>

impl<'a> Sync for FootnoteDef<'a>

impl<'a> Sync for Markdown<'a>

impl<'a> Sync for MarkdownItemInfo<'a>

impl<'a> Sync for MarkdownSummaryLine<'a>

impl<'a> Sync for MarkdownWithToc<'a>

impl<'a> Sync for ItemVars<'a>

impl<'a> Sync for Link<'a>

impl<'a> Sync for LinkBlock<'a>

impl<'a> Sync for Sidebar<'a>

impl<'a> Sync for ScrapedInfo<'a>

impl<'a> Sync for UnresolvedPath<'a>

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

impl<'a, 'b, 'ids, I> Sync for HeadingLinks<'a, 'b, 'ids, I>
where I: Sync,

impl<'a, 'tcx> !Sync for CacheBuilder<'a, 'tcx>

impl<'a, 'tcx> !Sync for HrefContext<'a, 'tcx>

impl<'a, 'tcx> !Sync for TagIterator<'a, 'tcx>

impl<'a, 'tcx> !Sync for LocalSourcesCollector<'a, 'tcx>

impl<'a, 'tcx> !Sync for SourceCollector<'a, 'tcx>

impl<'a, 'tcx> !Sync for DocTestVisibilityLinter<'a, 'tcx>

impl<'a, 'tcx> !Sync for LinkCollector<'a, 'tcx>

impl<'a, 'tcx> !Sync for SyntheticImplCollector<'a, 'tcx>

impl<'a, 'tcx> !Sync for Linter<'a, 'tcx>

impl<'a, 'tcx> !Sync for CfgPropagator<'a, 'tcx>

impl<'a, 'tcx> !Sync for StabilityPropagator<'a, 'tcx>

impl<'a, 'tcx> !Sync for Stripper<'a, 'tcx>

impl<'a, 'tcx> !Sync for ImplStripper<'a, 'tcx>

impl<'a, 'tcx> !Sync for Stripper<'a, 'tcx>

impl<'a, 'tcx> !Sync for FindCalls<'a, 'tcx>

impl<'a, 'tcx> !Sync for RustdocVisitor<'a, 'tcx>

impl<'a, 'tcx> !Sync for LibEmbargoVisitor<'a, 'tcx>

impl<'a, 'tcx> Sync for ContainerTy<'a, 'tcx>

impl<'a, 'tcx, F> !Sync for TokenHandler<'a, 'tcx, F>

impl<'a, Code> Sync for ScrapedSource<'a, Code>
where Code: Sync,

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

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

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

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

impl<'cache> !Sync for ItemAndAliasCollector<'cache>

impl<'cache, 'item> !Sync for AliasedType<'cache, 'item>

impl<'cache, 'item> !Sync for AliasedTypeImpl<'cache, 'item>

impl<'cx> Sync for TypeLayout<'cx>

impl<'cx, 'cache, 'item> !Sync for TypeImplCollector<'cx, 'cache, 'item>

impl<'hir> !Sync for Module<'hir>

impl<'p, 'a, I> Sync for CodeBlocks<'p, 'a, I>
where I: Sync,

impl<'src> Sync for Classifier<'src>

impl<'tcx> !Sync for DocContext<'tcx>

impl<'tcx> !Sync for EmitIgnoredResolutionErrors<'tcx>

impl<'tcx> !Sync for HirCollector<'tcx>

impl<'tcx> !Sync for ExtraInfo<'tcx>

impl<'tcx> !Sync for Context<'tcx>

impl<'tcx> !Sync for SharedContext<'tcx>

impl<'tcx> !Sync for SpanMapVisitor<'tcx>

impl<'tcx> !Sync for JsonRenderer<'tcx>

impl<'tcx> !Sync for AliasedNonLocalStripper<'tcx>

impl<'tcx> !Sync for NonLocalStripper<'tcx>

impl<'tcx> !Sync for ImportStripper<'tcx>

impl<'tcx> Sync for FunctionArgs<'tcx>

impl<'tcx> Sync for ObjectLifetimeDefault<'tcx>

impl<Code> Sync for Source<Code>
where Code: Sync,

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

impl<P> Sync for PartsAndLocations<P>
where P: Sync,

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

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

impl Sync for Abi

impl Sync for GenericArg

impl Sync for GenericArgs

impl Sync for ItemEnum

impl Sync for ItemKind

impl Sync for MacroKind

impl Sync for StructKind

impl Sync for Term

impl Sync for Type

impl Sync for VariantKind

impl Sync for Visibility

impl Sync for Constant

impl Sync for Crate

impl Sync for Deprecation

impl Sync for DynTrait

impl Sync for Enum

impl Sync for Function

impl Sync for Generics

impl Sync for Id

impl Sync for Impl

impl Sync for Item

impl Sync for ItemSummary

impl Sync for Module

impl Sync for Path

impl Sync for PolyTrait

impl Sync for Primitive

impl Sync for ProcMacro

impl Sync for Span

impl Sync for Static

impl Sync for Struct

impl Sync for Trait

impl Sync for TraitAlias

impl Sync for TypeAlias

impl Sync for Union

impl Sync for Use

impl Sync for Variant

impl !Sync for Data

impl !Sync for Span

impl !Sync for CodeFix

impl Sync for Filter

impl Sync for Error

impl Sync for Diagnostic

impl Sync for LineRange

impl Sync for Replacement

impl Sync for Snippet

impl Sync for Solution

impl Sync for Suggestion

impl Sync for HelpOp

impl Sync for Operation

impl Sync for Opts

impl Sync for Range

impl !Sync for MacroArg

impl !Sync for MacroArgKind

impl !Sync for Chain

impl !Sync for ChainItem

impl !Sync for SubExpr

impl !Sync for LineRange

impl !Sync for Config

impl !Sync for DiffEmitter

impl !Sync for UseSegment

impl !Sync for UseTree

impl !Sync for Macro

impl !Sync for MacroBranch

impl !Sync for ModItem

impl !Sync for ParseSess

impl !Sync for OutputWriter

impl !Sync for FormatReport

impl Sync for FileName

impl Sync for ListTactic

impl Sync for BraceStyle

impl Sync for Color

impl Sync for Density

impl Sync for Edition

impl Sync for EmitMode

impl Sync for Heuristics

impl Sync for IndentStyle

impl Sync for TypeDensity

impl Sync for Verbosity

impl Sync for Version

impl Sync for ErrorKind

impl Sync for Input

impl Sync for ExprType

impl Sync for RhsTactics

impl Sync for Timer

impl Sync for BracePos

impl Sync for Separator

impl Sync for SpaceState

impl Sync for ParserError

impl Sync for DiffLine

impl Sync for PathContext

impl Sync for FileLines

impl Sync for JsonSpan

impl Sync for Range

impl Sync for MacroName

impl Sync for ArrayWidth

impl Sync for ChainWidth

impl Sync for ColorConfig

impl Sync for FnCallWidth

impl Sync for HardTabs

impl Sync for Ignore

impl Sync for IgnoreList

impl Sync for MakeBackup

impl Sync for MaxWidth

impl Sync for TabSpaces

impl Sync for Verbose

impl Sync for ToTomlError

impl Sync for JsonEmitter

impl Sync for ListItem

impl Sync for PathVisitor

impl Sync for Directory

impl Sync for Mismatch

impl Sync for Indent

impl Sync for Shape

impl Sync for SkipContext

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

impl<'a> Sync for CommentStyle<'a>

impl<'a> Sync for VersionChunk<'a>

impl<'a> Sync for DocCommentFormatter<'a>

impl<'a> Sync for CommentCodeSlices<'a>

impl<'a> Sync for CommentReducer<'a>

impl<'a> Sync for LineClasses<'a>

impl<'a> Sync for Files<'a>

impl<'a> Sync for XmlEscaped<'a>

impl<'a> Sync for FormattedFile<'a>

impl<'a> Sync for PairParts<'a>

impl<'a> Sync for VersionChunkIter<'a>

impl<'a, 'ast> !Sync for SubModKind<'a, 'ast>

impl<'a, 'b, T> Sync for PairList<'a, 'b, T>
where T: Sync,

impl<'a, I, F1, F2, F3> Sync for ListItems<'a, I, F1, F2, F3>
where F1: Sync, F2: Sync, F3: Sync, I: Sync, <I as Iterator>::Item: Sync,

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

impl<'ast> !Sync for RhsAssignKind<'ast>

impl<'ast, 'psess> !Sync for ModResolver<'ast, 'psess>

impl<'b, T> !Sync for Session<'b, T>

impl<'c, 'g> !Sync for TyAliasRewriteInfo<'c, 'g>

impl<T> Sync for CharClasses<T>
where T: Sync, <T as Iterator>::Item: Sync,

impl Sync for FieldsShape

impl Sync for FloatLength

impl Sync for PassMode

impl Sync for Primitive

impl Sync for Scalar

impl Sync for TagEncoding

impl Sync for ValueAbi

impl Sync for CtorKind

impl Sync for ItemKind

impl Sync for GlobalAlloc

impl Sync for BinOp

impl Sync for BorrowKind

impl Sync for CastKind

impl Sync for Mutability

impl Sync for NullOp

impl Sync for Operand

impl Sync for RetagKind

impl Sync for Rvalue

impl Sync for Safety

impl Sync for UnOp

impl Sync for Variance

impl Sync for MonoItem

impl Sync for Endian

impl Sync for Abi

impl Sync for AdtKind

impl Sync for AliasKind

impl Sync for BoundTyKind

impl Sync for ClauseKind

impl Sync for ClosureKind

impl Sync for DynKind

impl Sync for FloatTy

impl Sync for IntTy

impl Sync for Movability

impl Sync for Pattern

impl Sync for RegionKind

impl Sync for RigidTy

impl Sync for TermKind

impl Sync for TyConstKind

impl Sync for TyKind

impl Sync for UintTy

impl Sync for ArgAbi

impl Sync for FnAbi

impl Sync for Layout

impl Sync for LayoutShape

impl Sync for TyAndLayout

impl Sync for Attribute

impl Sync for DefId

impl Sync for Error

impl Sync for AllocId

impl Sync for BasicBlock

impl Sync for Body

impl Sync for LocalDecl

impl Sync for Place

impl Sync for SourceInfo

impl Sync for Statement

impl Sync for Terminator

impl Sync for Instance

impl Sync for InstanceDef

impl Sync for StaticDef

impl Sync for Location

impl Sync for Crate

impl Sync for CrateItem

impl Sync for Opaque

impl Sync for MachineInfo

impl Sync for MachineSize

impl Sync for AdtDef

impl Sync for AliasDef

impl Sync for AliasTerm

impl Sync for AliasTy

impl Sync for Allocation

impl Sync for BoundRegion

impl Sync for BoundTy

impl Sync for BrNamedDef

impl Sync for ClosureDef

impl Sync for ConstDef

impl Sync for FieldDef

impl Sync for FnDef

impl Sync for FnSig

impl Sync for ForeignDef

impl Sync for GenericArgs

impl Sync for GenericDef

impl Sync for Generics

impl Sync for ImplDef

impl Sync for LineInfo

impl Sync for MirConst

impl Sync for MirConstId

impl Sync for ParamConst

impl Sync for ParamDef

impl Sync for ParamTy

impl Sync for Prov

impl Sync for Region

impl Sync for RegionDef

impl Sync for Span

impl Sync for TraitDecl

impl Sync for TraitDef

impl Sync for TraitRef

impl Sync for Ty

impl Sync for TyConst

impl Sync for TyConstId

impl Sync for TypeAndMut

impl Sync for VariantDef

impl Sync for VariantIdx

impl<'a> Sync for PlaceRef<'a>

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

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

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

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

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

impl Sync for Error

impl Sync for Status

impl Sync for Version

impl Sync for Directive

impl Sync for LIUState

impl Sync for Feature

impl<'a> Sync for RevisionInfo<'a>

impl<'a> Sync for ErrorAnnRev<'a>

impl<'ln> Sync for HeaderLine<'ln>