rustc_data_structures::sync

Trait Send

Source
pub unsafe auto trait Send { }
Expand description

Types that can be transferred across thread boundaries.

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

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

See the Nomicon and the Sync trait for more details.

Implementors§

Source§

impl !Send for Arguments<'_>

Source§

impl !Send for LocalWaker

Source§

impl !Send for Args

Source§

impl !Send for ArgsOs

Source§

impl Send for OwnedSlice

Source§

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

Source§

impl Send for Bytes<'_>

Source§

impl Send for Waker

Source§

impl Send for DroplessArena

Source§

impl Send for Select<'_>

Source§

impl Send for Collector

Source§

impl Send for Parker

Source§

impl Send for Unparker

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

§

impl<I, T> Send for IndexSlice<I, T>
where I: Idx, T: Send,

§

impl<I, T> Send for IndexVec<I, T>
where I: Idx, T: Send,

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

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

Source§

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

Source§

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

Source§

impl<T> !Send for ReentrantLockGuard<'_, T>
where T: ?Sized,

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

impl<T> Send for NonZero<T>

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

impl<T> Send for AtomicPtr<T>

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

impl<T> Send for JoinHandle<T>

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

impl<T> Send for Bucket<T>

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

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

Source§

impl<T: DynSend> Send for FromDyn<T>

impl<T> Send for Interned<T>

impl Send for ThinBuffer

impl Send for ThinData

impl Send for ArchiveRO

impl Send for ModuleLlvm

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

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

impl !Send for FatalError

Auto implementors§

§

impl !Send for RegistryId

§

impl !Send for ThreadData

§

impl Send for NodeStatus

§

impl Send for rustc_data_structures::obligation_forest::NodeState

§

impl Send for TimePassesFormat

§

impl Send for Mode

§

impl Send for BaseNString

§

impl Send for Fingerprint

§

impl Send for PackedFingerprint

§

impl Send for rustc_data_structures::flock::linux::Lock

§

impl Send for FxHasher

§

impl Send for PreorderIndex

§

impl Send for Time

§

impl Send for Direction

§

impl Send for EdgeIndex

§

impl Send for NodeIndex

§

impl Send for CycleDetector

§

impl Send for PrivateZst

§

impl Send for Client

§

impl Send for Mmap

§

impl Send for MmapMut

§

impl Send for ObligationTreeId

§

impl Send for Pu128

§

impl Send for EventFilter

§

impl Send for EventId

§

impl Send for QueryInvocationId

§

impl Send for SelfProfiler

§

impl Send for SelfProfilerRef

§

impl Send for VerboseInfo

§

impl Send for SmallCStr

§

impl Send for Hash64

§

impl Send for Hash128

§

impl Send for HashingControls

§

impl Send for SipHasher128Hash

§

impl Send for FatalErrorMarker

§

impl Send for Svh

§

impl Send for MaybeTempDir

§

impl Send for rustc_data_structures::transitive_relation::Edge

§

impl Send for Index

§

impl Send for NoUndo

§

impl Send for rustc_data_structures::undo_log::Snapshot

§

impl Send for Unhasher

§

impl Send for NoError

§

impl Send for ParallelGuard

§

impl Send for AtomicBool

§

impl Send for AtomicU32

§

impl Send for AtomicU64

§

impl Send for AtomicUsize

§

impl Send for Registry

§

impl Send for RegistryData

§

impl Send for ModeUnion

§

impl<'a> Send for JsonTimePassesEntry<'a>

§

impl<'a> Send for TimingGuard<'a>

§

impl<'a> Send for VerboseTimingGuard<'a>

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<'p> Send for EventArgRecorder<'p>

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<O> Send for rustc_data_structures::obligation_forest::Node<O>
where O: Send,

§

impl<O> Send for ObligationForest<O>
where O: Send, <O as ForestObligation>::CacheKey: Send,

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<T> Send for rustc_data_structures::sync::lock::maybe_sync::Lock<T>
where T: Send,

§

impl<T> Send for rustc_data_structures::sync::lock::no_sync::Lock<T>
where T: Send,

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

impl !Send for Cache

impl Send for EditorKind

impl Send for Profile

impl Send for SourceType

impl Send for Tool

impl Send for ToolState

impl Send for Alias

impl Send for Kind

impl Send for PathSet

impl Send for DryRun

impl Send for LldMode

impl Send for ReplaceOpt

impl Send for RustcLto

impl Send for StringOrInt

impl Send for Color

impl Send for Subcommand

impl Send for Warnings

impl Send for CLang

impl Send for DocTests

impl Send for GitRepo

impl Send for Mode

impl Send for Language

impl Send for GitInfo

impl Send for OutputMode

impl Send for LldThreads

impl Send for Message

impl Send for TestMessage

impl Send for OverlayKind

impl Send for Bootstrap

impl Send for CargoMiri

impl Send for Clippy

impl Send for Miri

impl Send for Rls

impl Send for Rustc

impl Send for Rustdoc

impl Send for Rustfmt

impl Send for Std

impl Send for CleanAll

impl Send for Rustc

impl Send for Std

impl Send for Bootstrap

impl Send for BuildHelper

impl Send for CargoMiri

impl Send for Clippy

impl Send for Compiletest

impl Send for Jsondocck

impl Send for Jsondoclint

impl Send for LintDocs

impl Send for Miri

impl Send for OptDist

impl Send for Rls

impl Send for Rustc

impl Send for Rustdoc

impl Send for Rustfmt

impl Send for Std

impl Send for Tidy

impl Send for Assemble

impl Send for Rustc

impl Send for RustcLink

impl Send for Std

impl Send for StdLink

impl Send for Sysroot

impl Send for Analysis

impl Send for Bootstrap

impl Send for Cargo

impl Send for Clippy

impl Send for Docs

impl Send for Extended

impl Send for JsonDocs

impl Send for LlvmTools

impl Send for Mingw

impl Send for Miri

impl Send for Rls

impl Send for RustDev

impl Send for Rustc

impl Send for RustcDev

impl Send for RustcDocs

impl Send for Rustfmt

impl Send for Src

impl Send for Std

impl Send for Bootstrap

impl Send for BuildHelper

impl Send for Cargo

impl Send for CargoBook

impl Send for Clippy

impl Send for ClippyBook

impl Send for Compiletest

impl Send for ErrorIndex

impl Send for Miri

impl Send for Nomicon

impl Send for Reference

impl Send for Releases

impl Send for Rustc

impl Send for RustcBook

impl Send for Rustdoc

impl Send for RustdocBook

impl Send for Rustfmt

impl Send for Standalone

impl Send for Std

impl Send for StyleGuide

impl Send for TheBook

impl Send for Tidy

impl Send for Gcc

impl Send for Meta

impl Send for Cargo

impl Send for Clippy

impl Send for Docs

impl Send for LlvmTools

impl Send for Miri

impl Send for Rustc

impl Send for Rustfmt

impl Send for Src

impl Send for Std

impl Send for CrtBeginEnd

impl Send for Enzyme

impl Send for LdFlags

impl Send for Libunwind

impl Send for Lld

impl Send for Llvm

impl Send for LlvmResult

impl Send for Meta

impl Send for Sanitizers

impl Send for BumpStage0

impl Send for Miri

impl Send for Editor

impl Send for Hook

impl Send for Link

impl Send for Assembly

impl Send for BookTest

impl Send for Bootstrap

impl Send for Cargo

impl Send for CargoMiri

impl Send for Cargotest

impl Send for Clippy

impl Send for Codegen

impl Send for CodegenGCC

impl Send for Compiletest

impl Send for Coverage

impl Send for CoverageMap

impl Send for CoverageRun

impl Send for Crashes

impl Send for Crate

impl Send for Debuginfo

impl Send for Distcheck

impl Send for ErrorIndex

impl Send for HtmlCheck

impl Send for Incremental

impl Send for Linkcheck

impl Send for LintDocs

impl Send for MirOpt

impl Send for Miri

impl Send for Nomicon

impl Send for Pretty

impl Send for Reference

impl Send for RunMake

impl Send for RustcBook

impl Send for RustcGuide

impl Send for Rustdoc

impl Send for RustdocBook

impl Send for RustdocGUI

impl Send for RustdocJson

impl Send for RustdocUi

impl Send for Rustfmt

impl Send for TestHelpers

impl Send for TheBook

impl Send for Tidy

impl Send for TierCheck

impl Send for Ui

impl Send for UiFullDeps

impl Send for BumpStage0

impl Send for Cargo

impl Send for CargoClippy

impl Send for CargoMiri

impl Send for CargoTest

impl Send for Cargofmt

impl Send for Clippy

impl Send for Compiletest

impl Send for ErrorIndex

impl Send for HtmlChecker

impl Send for JsonDocCk

impl Send for JsonDocLint

impl Send for Linkchecker

impl Send for LintDocs

impl Send for LldWrapper

impl Send for Miri

impl Send for Rls

impl Send for Rustbook

impl Send for RustcPerf

impl Send for Rustdoc

impl Send for Rustfmt

impl Send for Tidy

impl Send for ToolBuild

impl Send for RepoState

impl Send for Vendor

impl Send for Cargo

impl Send for HostFlags

impl Send for Rustflags

impl Send for TaskPath

impl Send for Build

impl Send for Config

impl Send for Dist

impl Send for Install

impl Send for Llvm

impl Send for Rust

impl Send for Target

impl Send for TomlConfig

impl Send for TomlTarget

impl Send for Flags

impl Send for Dependency

impl Send for Output

impl Send for Package

impl Send for Target

impl Send for Finder

impl Send for Build

impl Send for Compiler

impl Send for Crate

impl Send for Interner

impl Send for ChangeInfo

impl Send for Info

impl Send for HashStamp

impl Send for TimeIt

impl Send for TestOutcome

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

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

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

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

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

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

impl<'a> Send for CargoMessage<'a>

impl<'a> Send for Outcome<'a>

impl<'a> Send for CargoTarget<'a>

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

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

impl Send for CiEnv

impl Send for JsonNode

impl Send for TestOutcome

impl Send for Group

impl Send for DropBomb

impl Send for JsonRoot

impl Send for Test

impl Send for TestSuite

impl Send for Stage0

impl<'a> Send for GitConfig<'a>

impl !Send for ShellOut

impl !Send for MaybePackage

impl !Send for MaybePackage

impl !Send for BuildConfig

impl !Send for TargetInfo

impl !Send for Doctest

impl !Send for UnitOutput

impl !Send for UnitTime

impl !Send for Unit

impl !Send for UnitInner

impl !Send for UnitInterner

impl !Send for UnitDep

impl !Send for Manifest

impl !Send for Package

impl !Send for PackageInner

impl !Send for CliFeatures

impl !Send for Resolve

impl !Send for DepsFrame

impl !Send for ResolveOpts

impl !Send for Shell

impl !Send for DocOptions

impl !Send for TestOptions

impl !Send for FixOptions

impl !Send for PublishPlan

impl !Send for TreeOptions

impl !Send for GitShortID

impl !Send for TargetConfig

impl Send for CompileMode

impl Send for FileFlavor

impl Send for Flags

impl Send for ToolKind

impl Send for CompileKind

impl Send for CrateType

impl Send for DirtyReason

impl Send for FsStatus

impl Send for StaleItem

impl Send for Artifact

impl Send for Message

impl Send for Freshness

impl Send for Lto

impl Send for IsArtifact

impl Send for DepKind

impl Send for Edition

impl Send for Status

impl Send for TargetKind

impl Send for DebugInfo

impl Send for Lto

impl Send for ProfileRoot

impl Send for Strip

impl Send for StripInner

impl Send for Kind

impl Send for FeaturesFor

impl Send for HasDevUnits

impl Send for ColorChoice

impl Send for TtyWidth

impl Send for Verbosity

impl Send for KeyOf

impl Send for Precise

impl Send for FilterRule

impl Send for LibRule

impl Send for Packages

impl Send for TestKind

impl Send for Prefix

impl Send for Target

impl Send for Chunk

impl Send for EdgeKind

impl Send for Node

impl Send for RemoteKind

impl Send for OpenMode

impl Send for Revision

impl Send for FastPathRev

impl Send for MaybeLock

impl Send for StatusCode

impl Send for QueryKind

impl Send for CommandInfo

impl Send for KeyKind

impl Send for ConfigValue

impl Send for JobsConfig

impl Send for Tool

impl Send for WhyLoad

impl Send for Definition

impl Send for Message

impl Send for LintLevel

impl Send for Source

impl Send for FileType

impl Send for BuildPlan

impl Send for Invocation

impl Send for MetaInfo

impl Send for Metadata

impl Send for OutputFile

impl Send for BuildDeps

impl Send for BuildOutput

impl Send for After

impl Send for Checksum

impl Send for Fingerprint

impl Send for Diagnostic

impl Send for Job

impl Send for Work

impl Send for JobId

impl Send for Layout

impl Send for Concurrency

impl Send for Artifact

impl Send for Dependency

impl Send for Inner

impl Send for CliUnstable

impl Send for Feature

impl Send for Features

impl Send for GitFeatures

impl Send for AutoConfig

impl Send for GcOpts

impl Send for BasePaths

impl Send for GitCheckout

impl Send for GitDb

impl Send for ParentId

impl Send for RegistrySrc

impl Send for Target

impl Send for TargetInner

impl Send for Warnings

impl Send for PackageId

impl Send for Profile

impl Send for Profiles

impl Send for UnitFor

impl Send for Patch

impl Send for FeatureOpts

impl Send for SourceId

impl Send for Inner

impl Send for Summary

impl Send for CrateSpec

impl Send for DepOp

impl Send for Transaction

impl Send for IgnoreList

impl Send for NewOptions

impl Send for Dep

impl Send for DepKindInfo

impl Send for ExportInfo

impl Send for ArchiveFile

impl Send for GitVcsInfo

impl Send for VcsInfo

impl Send for PackageDiff

impl Send for InstallInfo

impl Send for FixArgs

impl Send for FixedCrate

impl Send for FixedFile

impl Send for Pattern

impl Send for Edges

impl Send for Symbols

impl Send for Checksum

impl Send for KnownHost

impl Send for GitDatabase

impl Send for GitRemote

impl Send for Headers

impl Send for Summaries

impl Send for CacheLocker

impl Send for CacheState

impl Send for Env

impl Send for ConfigKey

impl Send for PathAndArgs

impl Send for ConfigError

impl Send for StringList

impl Send for TermConfig

impl Send for ValueKey

impl Send for State

impl Send for State

impl Send for CliError

impl Send for FileLock

impl Send for Filesystem

impl Send for Lint

impl Send for LintGroup

impl Send for LockServer

impl Send for HttpTimeout

impl Send for Format

impl Send for Throttle

impl Send for Cache

impl Send for CacheData

impl Send for Output

impl Send for Rustc

impl Send for Dependency

impl Send for GitSource

impl Send for PathSource

impl Send for DepTable

impl Send for Manifest

impl Send for FossilRepo

impl Send for GitRepo

impl Send for HgRepo

impl Send for PijulRepo

impl Send for CommitInfo

impl Send for VersionInfo

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

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

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

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

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

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

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

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

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

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

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

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

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

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

impl<'a> Send for WhyTick<'a>

impl<'a> Send for RawChunk<'a>

impl<'a> Send for SerializedUnit<'a>

impl<'a> Send for SerializedUnitGraph<'a>

impl<'a> Send for SerializedArtifact<'a>

impl<'a> Send for SerializedTarget<'a>

impl<'a> Send for PackageIdStableHash<'a>

impl<'a> Send for Requirements<'a>

impl<'a> Send for EncodeState<'a>

impl<'a> Send for SourceIdAsUrl<'a>

impl<'a> Send for GetOptions<'a>

impl<'a> Send for MkOptions<'a>

impl<'a> Send for Parser<'a>

impl<'a> Send for VendorOptions<'a>

impl<'a> Send for SummariesCache<'a>

impl<'a> Send for IndexPackage<'a>

impl<'a> Send for RegistryDependency<'a>

impl<'a> Send for Footer<'a>

impl<'a> Send for Message<'a>

impl<'a> Send for ManifestCauses<'a>

impl<'a> Send for Artifact<'a>

impl<'a> Send for BuildScript<'a>

impl<'a> Send for FromCompiler<'a>

impl<'a> Send for TimingInfo<'a>

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

impl<'s> Send for Source<'s>

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

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

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

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

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

impl<T> !Send for RcVecIter<T>

impl<T> !Send for LocalDependencies<T>

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

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

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

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

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

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

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

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

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

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

impl Send for Error

impl Send for Stdio

impl<'a> Send for Action<'a>

impl<'a> Send for Operation<'a>

impl<'a> Send for CredentialRequest<'a>

impl<'a> Send for LoginOptions<'a>

impl<'a> Send for RegistryInfo<'a>

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

impl Send for Verbosity

impl Send for Opts

impl Send for Target

impl Send for Cfg

impl Send for CfgExpr

impl Send for Platform

impl Send for ParseError

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

impl<'a> Send for Parser<'a>

impl<'a> Send for Tokenizer<'a>

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

impl Send for EntryData

impl Send for Token

impl Send for InMemoryDir

impl Send for Container

impl Send for MkFile

impl Send for RepoBuilder

impl Send for Repository

impl Send for TestIdGuard

impl Send for Dependency

impl Send for HttpServer

impl Send for Package

impl Send for PackageFile

impl Send for Request

impl Send for Response

impl Send for Execs

impl Send for FileBuilder

impl Send for Project

impl Send for RawOutput

impl Send for RustcInfo

impl<'a> Send for WildStr<'a>

impl<'a> Send for Mutation<'a>

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

impl Send for Sha256

impl<'a> Send for PathAncestors<'a>

impl Send for ErrorKind

impl Send for ErrorKind

impl Send for SourceKind

impl Send for TomlLint

impl Send for ErrorKind

impl Send for RustVersion

impl Send for PathValue

impl Send for StringOrVec

impl Send for TomlPackage

impl Send for TomlProfile

impl Send for TomlTarget

impl<'a> Send for PrettyRef<'a>

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

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

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

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

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

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

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

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

impl Send for Field

impl Send for Conf

impl Send for ConfError

impl Send for FieldError

impl Send for Suggestion

impl Send for TryConf

impl Send for Msrv

impl Send for Rename

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

impl !Send for SourceText

impl Send for Pat

impl Send for Rel

impl Send for FullInt

impl Send for CaptureKind

impl Send for VecInitKind

impl Send for PathCheck

impl Send for Radix

impl Send for EnumValue

impl Send for Certainty

impl Send for Descend

impl Send for IdentIter

impl Send for LimitStack

impl Send for MacroCall

impl Send for LocalUsage

impl Send for StrCount

impl Send for StrIndex

impl<'a> Send for VecArgs<'a>

impl<'a> Send for PanicExpn<'a>

impl<'a> Send for Sugg<'a>

impl<'a> Send for Range<'a>

impl<'a> Send for V<'a>

impl<'a> Send for NumericLiteral<'a>

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

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

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

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

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

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

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

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

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

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

impl<'hir> Send for IfLetOrMatch<'hir>

impl<'hir> Send for If<'hir>

impl<'hir> Send for IfLet<'hir>

impl<'hir> Send for IfOrIfLet<'hir>

impl<'hir> Send for While<'hir>

impl<'hir> Send for WhileLet<'hir>

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

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

impl<'tcx> Send for Constant<'tcx>

impl<'tcx> Send for DefinedTy<'tcx>

impl<'tcx> Send for ExprUseNode<'tcx>

impl<'tcx> Send for ExprFnSig<'tcx>

impl<'tcx> Send for ForLoop<'tcx>

impl<'tcx> Send for InteriorMut<'tcx>

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

impl Send for CompareMode

impl Send for Debugger

impl Send for Endian

impl Send for FailMode

impl Send for Mode

impl Send for PassMode

impl Send for Sanitizer

impl Send for DiffLine

impl Send for ErrorKind

impl Send for WhichLine

impl Send for ProcOutput

impl Send for Truncated

impl Send for AllowUnused

impl Send for AuxType

impl Send for Emit

impl Send for LinkToAux

impl Send for ReadFrom

impl Send for TestOutput

impl Send for WillExecute

impl Send for Config

impl Send for TargetCfg

impl Send for TargetCfgs

impl Send for TestPaths

impl Send for Mismatch

impl Send for Error

impl Send for AuxProps

impl Send for Need

impl Send for EarlyProps

impl Send for TestProps

impl Send for Diagnostic

impl Send for ProcArgs

impl Send for ProcRes

impl Send for Stamp

impl<'a> Send for ParsedNameDirective<'a>

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

impl<'ln> Send for CheckDirectiveResult<'ln>

impl<'ln> Send for DirectiveLine<'ln>

impl<'test> Send for TestCx<'test>

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

impl Send for Auth

impl Send for Error

impl Send for ApiError

impl Send for Crate

impl Send for Crates

impl Send for NewCrate

impl Send for R

impl Send for Registry

impl Send for TotalCrates

impl Send for User

impl Send for Users

impl Send for Warnings

impl<'a> Send for OwnersReq<'a>

impl Send for Config

impl Send for NullOptions

impl Send for Format

impl Send for Font

impl Send for MdFormatter

impl Send for Table

impl Send for lower

impl<'a> Send for ManLinkHelper<'a>

impl<'a> Send for OptionHelper<'a>

impl<'a> Send for OptionsHelper<'a>

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

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

impl !Send for CArg

impl !Send for FdTable

impl !Send for Epoll

impl !Send for AnonSocket

impl Send for AllocState

impl Send for RetagFields

impl Send for Operation

impl Send for RetagCause

impl Send for Permission

impl Send for AccessCause

impl Send for ClockKind

impl Send for InstantKind

impl Send for AccessType

impl Send for AtomicRwOrd

impl Send for NaReadType

impl Send for NaWriteType

impl Send for AccessType

impl Send for BlockReason

impl Send for Timeout

impl Send for LoadRecency

impl Send for DiagLevel

impl Send for IsolatedOp

impl Send for AccessKind

impl Send for AtomicOp

impl Send for MinMax

impl Send for Provenance

impl Send for IoError

impl Send for FlockOp

impl Send for ClockId

impl Send for MutexKind

impl Send for Handle

impl Send for FloatBinOp

impl Send for ShiftOp

impl Send for ReusePool

impl Send for AccessOp

impl Send for Creation

impl Send for DeallocOp

impl Send for Protection

impl Send for RetagInfo

impl Send for RetagOp

impl Send for TagHistory

impl Send for Item

impl Send for Stack

impl Send for StackCache

impl Send for Stacks

impl Send for BorTag

impl Send for FrameState

impl Send for DisplayFmt

impl Send for DisplayRepr

impl Send for Event

impl Send for History

impl Send for HistoryData

impl Send for Permission

impl Send for Node

impl Send for Tree

impl Send for UniIndex

impl Send for Clock

impl Send for Instant

impl Send for DataRace

impl Send for FrameState

impl Send for GlobalState

impl Send for LocalClocks

impl Send for VClockAlloc

impl Send for InitOnce

impl Send for InitOnceId

impl Send for Condvar

impl Send for CondvarId

impl Send for Futex

impl Send for FutexWaiter

impl Send for Mutex

impl Send for MutexId

impl Send for RwLock

impl Send for RwLockId

impl Send for ThreadId

impl Send for VClock

impl Send for VTimestamp

impl Send for VectorIdx

impl Send for LoadInfo

impl Send for StoreBuffer

impl Send for RacingOp

impl Send for MiriConfig

impl Send for DynSym

impl Send for FdId

impl Send for NullOutput

impl Send for DirTable

impl Send for FileHandle

impl Send for OpenDir

impl Send for ReadyList

impl Send for Event

impl Send for Buffer

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

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

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

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

impl<'node> Send for TbError<'node>

impl<'node> Send for NodeAppArgs<'node>

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

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

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

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

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

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

impl<'tcx> Send for MainThreadState<'tcx>

impl<'tcx> Send for EnvVars<'tcx>

impl<'tcx> Send for TlsDtorsStatePriv<'tcx>

impl<'tcx> Send for FrameExtra<'tcx>

impl<'tcx> Send for PrimitiveLayouts<'tcx>

impl<'tcx> Send for CatchUnwindData<'tcx>

impl<'tcx> Send for TlsData<'tcx>

impl<'tcx> Send for TlsDtorsState<'tcx>

impl<'tcx> Send for TlsEntry<'tcx>

impl<'tcx> Send for UnixEnvVars<'tcx>

impl<'tree> Send for TreeVisitor<'tree>

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

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

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

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

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

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

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

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

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

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

impl Send for Command

impl Send for Diff

impl Send for Cc

impl Send for Clang

impl Send for LlvmAr

impl Send for LlvmDis

impl Send for LlvmNm

impl Send for LlvmObjcopy

impl Send for LlvmObjdump

impl Send for LlvmPdbutil

impl Send for LlvmReadobj

impl Send for Rustc

impl Send for Rustdoc

impl Send for RegKind

impl Send for Abi

impl Send for Endian

impl Send for Float

impl Send for Integer

impl Send for IntegerType

impl Send for PointerKind

impl Send for Primitive

impl Send for Scalar

impl Send for StructKind

impl Send for NicheBias

impl Send for Reg

impl Send for FieldIdx

impl Send for VariantIdx

impl Send for Align

impl Send for Niche

impl Send for PointeeInfo

impl Send for ReprFlags

impl Send for ReprOptions

impl Send for Size

impl<'a> Send for TargetDataLayoutErrors<'a>

impl<'a> Send for Layout<'a>

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

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

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

impl<FieldIdx> Send for FieldsShape<FieldIdx>

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

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

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

impl !Send for AttrArgs

impl !Send for AttrArgsEq

impl !Send for AttrKind

impl !Send for ExprKind

impl !Send for FnRetTy

impl !Send for GenericArg

impl !Send for GenericArgs

impl !Send for GenericBound

impl !Send for ItemKind

impl !Send for LocalKind

impl !Send for MetaItemKind

impl !Send for ModKind

impl !Send for PatKind

impl !Send for SelfKind

impl !Send for StmtKind

impl !Send for StructRest

impl !Send for Term

impl !Send for TyKind

impl !Send for UseTreeKind

impl !Send for VariantData

impl !Send for Nonterminal

impl !Send for TokenKind

impl !Send for TokenTree

impl !Send for AnonConst

impl !Send for Arm

impl !Send for AttrItem

impl !Send for Attribute

impl !Send for BareFnTy

impl !Send for Block

impl !Send for Closure

impl !Send for ConstItem

impl !Send for Crate

impl !Send for Delegation

impl !Send for DelimArgs

impl !Send for EnumDef

impl !Send for Expr

impl !Send for ExprField

impl !Send for FieldDef

impl !Send for Fn

impl !Send for FnDecl

impl !Send for FnSig

impl !Send for ForeignMod

impl !Send for GenericParam

impl !Send for Generics

impl !Send for Impl

impl !Send for InlineAsm

impl !Send for InlineAsmSym

impl !Send for Local

impl !Send for MacCall

impl !Send for MacCallStmt

impl !Send for MacroDef

impl !Send for MetaItem

impl !Send for MethodCall

impl !Send for MutTy

impl !Send for NormalAttr

impl !Send for Param

impl !Send for Pat

impl !Send for PatField

impl !Send for Path

impl !Send for PathSegment

impl !Send for PolyTraitRef

impl !Send for QSelf

impl !Send for StaticItem

impl !Send for Stmt

impl !Send for StructExpr

impl !Send for Trait

impl !Send for TraitRef

impl !Send for Ty

impl !Send for TyAlias

impl !Send for UseTree

impl !Send for Variant

impl !Send for Visibility

impl !Send for WhereClause

impl !Send for FormatArgs

impl !Send for Token

impl !Send for AttrsTarget

impl !Send for TokenStream

impl Send for AsmMacro

impl Send for AttrStyle

impl Send for BinOpKind

impl Send for BorrowKind

impl Send for ByRef

impl Send for CaptureBy

impl Send for Const

impl Send for Defaultness

impl Send for Extern

impl Send for FloatTy

impl Send for ForLoopKind

impl Send for Inline

impl Send for IntTy

impl Send for IsAuto

impl Send for LitIntType

impl Send for LitKind

impl Send for MatchKind

impl Send for RangeEnd

impl Send for RangeLimits

impl Send for RangeSyntax

impl Send for Recovered

impl Send for Safety

impl Send for StrStyle

impl Send for UintTy

impl Send for UnOp

impl Send for AllocatorTy

impl Send for DiffMode

impl Send for Kind

impl Send for FormatCount

impl Send for FormatSign

impl Send for FormatTrait

impl Send for BinOpToken

impl Send for CommentKind

impl Send for Delimiter

impl Send for IdentIsRaw

impl Send for LitKind

impl Send for NtExprKind

impl Send for NtPatKind

impl Send for Spacing

impl Send for Case

impl Send for LitError

impl Send for AssocOp

impl Send for Fixity

impl Send for AssocCtxt

impl Send for BoundKind

impl Send for FnCtxt

impl Send for BindingMode

impl Send for FnHeader

impl Send for Label

impl Send for Lifetime

impl Send for MetaItemLit

impl Send for ModSpans

impl Send for StrLit

impl Send for MarkedAttrs

impl Send for FncTree

impl Send for Type

impl Send for TypeTree

impl Send for NodeId

impl Send for Lit

impl Send for DelimSpan

impl Send for Comment

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

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

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

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

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

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

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

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

impl Send for Movability

impl Send for Mutability

impl Send for Pinnedness

impl Send for FnDeclKind

impl Send for ParamMode

impl Send for FutureKind

impl Send for InvalidAbi

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

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

impl<'a> Send for SelfResolver<'a>

impl<'a> Send for ExtraDoubleDot<'a>

impl<'a> Send for InvalidRegister<'a>

impl<'a> Send for InvalidRegisterClass<'a>

impl<'a> Send for RegisterConflict<'a>

impl<'a> Send for SubTupleBinding<'a>

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

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

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

impl<'ast> Send for LifetimeCollectVisitor<'ast>

impl<'hir> Send for DelegationResults<'hir>

impl<'hir> Send for GenericArgsCtor<'hir>

impl Send for Mode

impl Send for ShowSpan

impl Send for UnsafeItem

impl Send for NodeCounter

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

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

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

impl<'a> Send for BodyInExtern<'a>

impl<'a> Send for BoundInContext<'a>

impl<'a> Send for ExternTypesCannotHave<'a>

impl<'a> Send for InherentImplCannot<'a>

impl<'a> Send for ItemUnderscore<'a>

impl<'a> Send for OutOfOrderParams<'a>

impl Send for Breaks

impl Send for IndentStyle

impl Send for PrintFrame

impl Send for Token

impl Send for BeginToken

impl Send for BreakToken

impl Send for BufEntry

impl Send for Printer

impl Send for NoAnn

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

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

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

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

impl<'a> Send for DelegationKind<'a>

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

impl Send for InlineAttr

impl Send for IntType

impl Send for ReprAttr

impl Send for StableSince

impl Send for Condition

impl Send for Deprecation

impl Send for Stability

impl Send for MissingNote

impl Send for SoftNoArgs

impl<'a> Send for InvalidReprGeneric<'a>

impl<'a> Send for UnknownMetaItem<'a>

impl Send for DefUse

impl Send for AccessKind

impl Send for AccessDepth

impl Send for Overlap

impl Send for ReadKind

impl Send for ReadOrWrite

impl Send for WriteKind

impl Send for Control

impl Send for PrefixSet

impl Send for Cause

impl Send for RegionCtxt

impl Send for Locations

impl Send for Normal

impl Send for Reverse

impl Send for BorrowIndex

impl Send for BreakFinder

impl Send for MoveSite

impl Send for RegionName

impl Send for RustcFacts

impl Send for LiveLoans

impl Send for FnMutError

impl Send for Appearance

impl Send for LocalUseMap

impl<'a> Send for CaptureReasonLabel<'a>

impl<'a> Send for OnClosureNote<'a>

impl<'a> Send for MoveBorrow<'a>

impl<'a> Send for AppearancesIter<'a>

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

impl<'a, 'tcx> !Send for BorrowCheckContext<'a, 'tcx>

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

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

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

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

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

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

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

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

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

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

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

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

impl<'me> Send for LocalUseMapBuild<'me>

impl<'tcx> !Send for UniverseInfoInner<'tcx>

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

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

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

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

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

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

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

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

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

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

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

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

impl<'tcx> Send for AnnotatedBorrowFnSignature<'tcx>

impl<'tcx> Send for StorageDeadOrDrop<'tcx>

impl<'tcx> Send for BorrowedContentSource<'tcx>

impl<'tcx> Send for UseSpans<'tcx>

impl<'tcx> Send for BorrowExplanation<'tcx>

impl<'tcx> Send for GroupedMoveError<'tcx>

impl<'tcx> Send for IllegalMoveOriginKind<'tcx>

impl<'tcx> Send for RegionErrorKind<'tcx>

impl<'tcx> Send for Trace<'tcx>

impl<'tcx> Send for CaptureReasonSuggest<'tcx>

impl<'tcx> Send for DefiningTy<'tcx>

impl<'tcx> Send for BorrowData<'tcx>

impl<'tcx> Send for BorrowSet<'tcx>

impl<'tcx> Send for OutlivesConstraint<'tcx>

impl<'tcx> Send for OutlivesConstraintSet<'tcx>

impl<'tcx> Send for AscribeUserTypeQuery<'tcx>

impl<'tcx> Send for PredicateQuery<'tcx>

impl<'tcx> Send for MoveError<'tcx>

impl<'tcx> Send for ErrorConstraintInfo<'tcx>

impl<'tcx> Send for NllMemberConstraint<'tcx>

impl<'tcx> Send for Prefixes<'tcx>

impl<'tcx> Send for BlameConstraint<'tcx>

impl<'tcx> Send for RegionDefinition<'tcx>

impl<'tcx> Send for TypeTest<'tcx>

impl<'tcx> Send for LifetimeMismatchOpaqueParam<'tcx>

impl<'tcx> Send for MoveUnsized<'tcx>

impl<'tcx> Send for RootPlace<'tcx>

impl<'tcx> Send for TyCtxtConsts<'tcx>

impl<'tcx> Send for DropData<'tcx>

impl<'tcx> Send for InstantiateOpaqueType<'tcx>

impl<'tcx> Send for UniversalRegionIndices<'tcx>

impl<'tcx> Send for UniversalRegions<'tcx>

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

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

impl<'w> Send for FactWriter<'w>

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

impl<N> !Send for RegionValues<N>

impl !Send for AsmArgs

impl !Send for Capture

impl !Send for Assert

impl !Send for BlockOrExpr

impl !Send for FieldInfo

impl !Send for MacroInput

impl Send for IsTuple

impl Send for PathKind

impl Send for Ty

impl Send for Num

impl Send for State

impl Send for ProcMacro

impl Send for ShouldPanic

impl Send for TestType

impl Send for Expander

impl Send for Expander

impl Send for Bounds

impl Send for Path

impl Send for AsmNoReturn

impl Send for BenchSig

impl Send for DeriveUnion

impl Send for NonABI

impl Send for ProcMacro

impl Send for TestBadFn

impl Send for TraceMacros

impl Send for Test

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

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

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

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

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

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

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

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

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

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

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

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

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

impl<'a> Send for Substitution<'a>

impl<'a> Send for Substitution<'a>

impl<'a> Send for AsmUnsupportedOperand<'a>

impl<'a> Send for ExpectedItem<'a>

impl<'a> Send for FormatUnknownTrait<'a>

impl<'a> Send for OnlyOneArgument<'a>

impl<'a> Send for TakesNoArguments<'a>

impl<'a> Send for Format<'a>

impl<'a> Send for Substitutions<'a>

impl<'a> Send for Substitutions<'a>

impl<'a> Send for StrCursor<'a>

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

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

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

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

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

impl !Send for Addition

impl !Send for DebugLoc

impl Send for CounterKind

impl Send for ExprKind

impl Send for DiscrResult

impl Send for WidePtrKind

impl Send for ArchiveKind

impl Send for AsmDialect

impl Send for CallConv

impl Send for CodeModel

impl Send for FileType

impl Send for Linkage

impl Send for OptStage

impl Send for RelocModel

impl Send for TypeKind

impl Send for UnnamedAddr

impl Send for Visibility

impl Send for CodeRegion

impl Send for Counter

impl Send for LocalFileId

impl Send for Split128

impl Send for HiddenZst

impl Send for CopyBitcode

impl Send for LtoDylib

impl Send for DIFlags

impl Send for DISPFlags

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

impl<'a> Send for LlvmError<'a>

impl<'a> Send for PossibleFeature<'a>

impl<'a> Send for LlvmSelfProfiler<'a>

impl<'a> Send for FixedX18InvalidArch<'a>

impl<'a> Send for MismatchedDataLayout<'a>

impl<'a> Send for SymbolAlreadyDefined<'a>

impl<'a> Send for UnknownCTargetFeature<'a>

impl<'a> Send for UnstableCTargetFeature<'a>

impl<'a> Send for WithLlvmError<'a>

impl<'a> Send for WriteBytecode<'a>

impl<'a> Send for LLVMFeature<'a>

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

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

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

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

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

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

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

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

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

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

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

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

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

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

impl<'tcx> Send for UniqueTypeId<'tcx>

impl<'tcx> Send for FunctionCoverage<'tcx>

impl<'tcx> Send for FunctionCoverageCollector<'tcx>

impl<'tcx> Send for UsageSets<'tcx>

impl<T> Send for RawEnum<T>

impl !Send for CrateInfo

impl !Send for NativeLib

impl Send for CguReuse

impl Send for Program

impl Send for RlibFlavor

impl Send for EmitObj

impl Send for TypeKind

impl Send for ModuleKind

impl Send for CleanupKind

impl Send for LocalKind

impl Send for MergingSucc

impl Send for OverflowOp

impl Send for TrackerData

impl Send for Command

impl Send for CguMessage

impl Send for Diagnostic

impl Send for CopyPathBuf

impl Send for NoField

impl Send for MemFlags

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

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

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

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

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

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

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

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

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

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

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

impl<'a> Send for AppleSdkRootError<'a>

impl<'a> Send for RPathConfig<'a>

impl<'a> Send for CguNotRecorded<'a>

impl<'a> Send for CopyPath<'a>

impl<'a> Send for DebugArgPath<'a>

impl<'a> Send for ErrorCallingDllTool<'a>

impl<'a> Send for IncorrectCguReuseType<'a>

impl<'a> Send for LinkingFailed<'a>

impl<'a> Send for NoModuleNamed<'a>

impl<'a> Send for NoSavedObjectFile<'a>

impl<'a> Send for UnableToRun<'a>

impl<'a> Send for UnknownArchiveKind<'a>

impl<'a> Send for UnsupportedArch<'a>

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

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

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

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

impl<'tcx> Send for InvalidMonomorphization<'tcx>

impl<'tcx> Send for GlobalAsmOperandRef<'tcx>

impl<'tcx> Send for FailedToGetLayout<'tcx>

impl<'tcx> Send for TerminatorCodegenHelper<'tcx>

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

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

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

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

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

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

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

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

impl<B> !Send for OngoingCodegen<B>

impl<B> Send for LtoModuleCodegen<B>

impl<B> Send for FatLtoInput<B>

impl<B> Send for Message<B>

impl<B> Send for WorkItem<B>

impl<B> Send for WorkItemResult<B>

impl<B> Send for ThinModule<B>

impl<B> Send for ThinShared<B>

impl<B> Send for CodegenContext<B>

impl<B> Send for Coordinator<B>

impl<M> Send for SerializedModule<M>

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

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

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

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

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

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

impl !Send for SpanGuard

impl Send for Status

impl Send for MemoryKind

impl Send for InternKind

impl Send for AllocKind

impl Send for OffsetMode

impl Send for PathElem

impl Send for Coroutine

impl Send for InlineAsm

impl Send for PanicNonStr

impl Send for NeedsDrop

impl Send for State

impl Send for FrameNote

impl Send for LongRunning

impl Send for RangeSet

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

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

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

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

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

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

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

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

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

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

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

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

impl<'tcx> Send for ValTreeCreationError<'tcx>

impl<'tcx> Send for FnCallNonConst<'tcx>

impl<'tcx> Send for LiveDrop<'tcx>

impl<'tcx> Send for LiveDrop<'tcx>

impl<'tcx> Send for NonConstAwait<'tcx>

impl<'tcx> Send for NonConstDerefCoercion<'tcx>

impl<'tcx> Send for NonConstForLoopIntoIter<'tcx>

impl<'tcx> Send for NonConstMatchEq<'tcx>

impl<'tcx> Send for NonConstQuestionBranch<'tcx>

impl<'tcx> Send for NonConstQuestionFromResidual<'tcx>

impl<'tcx> Send for NonConstTryBlockFromOutput<'tcx>

impl<'tcx> Send for FrameInfo<'tcx>

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

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

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

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

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

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

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

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

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

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

impl<'tcx, Prov> Send for LocalState<'tcx, Prov>
where Prov: Send,

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

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

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

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

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

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

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

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

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

impl Send for Error

impl Send for Compilation

impl Send for Expander

impl Send for AstNoAnn

impl Send for Ice

impl Send for IceFlags

impl Send for IcePath

impl Send for RawStderr

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

impl<'a> Send for IceBugReport<'a>

impl<'a> Send for IceVersion<'a>

impl<'a> Send for RlinkCorruptFile<'a>

impl<'a> Send for RunCompiler<'a>

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

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

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

impl Send for DiagMessage

impl Send for MultiSpan

impl Send for SpanLabel

impl !Send for HumanEmitter

impl !Send for JsonEmitter

impl !Send for DiagCtxt

impl Send for ColorConfig

impl Send for Level

impl Send for StashKey

impl Send for Suggestions

impl Send for TerminalUrl

impl Send for BreakRule

impl Send for ParseOpt

impl Send for Prev

impl Send for Style

impl Send for ErrCode

impl Send for BugAbort

impl Send for DiagInner

impl Send for FatalAbort

impl Send for IsLint

impl Send for StringPart

impl Send for Subdiag

impl Send for Buffy

impl Send for Margin

impl Send for Diagnostic

impl Send for Context

impl Send for Registry

impl Send for Annotation

impl Send for Line

impl Send for ExplicitBug

impl Send for StyledChar

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

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

impl<'a> Send for EmitTyped<'a>

impl<'a> Send for MdTree<'a>

impl<'a> Send for ArtifactNotification<'a>

impl<'a> Send for FutureBreakageItem<'a>

impl<'a> Send for FutureIncompatReport<'a>

impl<'a> Send for UnusedExterns<'a>

impl<'a> Send for MdStream<'a>

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

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

impl<'args> Send for TranslateErrorKind<'args>

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

impl !Send for Annotatable

impl !Send for AstFragment

impl !Send for TokenTree

impl !Send for MatcherLoc

impl !Send for NamedMatch

impl !Send for FrameKind

impl !Send for MacEager

impl !Send for Invocation

impl !Send for BestFailure

impl !Send for MatcherPos

impl !Send for TtParser

impl !Send for Delimited

impl Send for InvalidCfg

impl Send for KleeneOp

impl Send for CanRetry

impl Send for IsInFollow

impl Send for MetaVarExpr

impl Send for DummyResult

impl Send for ModuleData

impl Send for OnlyOneWord

impl Send for TraceMacro

impl Send for ImplItemTag

impl Send for OptExprTag

impl Send for BinderInfo

impl Send for NoopTracker

impl Send for KleeneToken

impl Send for Marker

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

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

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

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

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

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

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

impl<'a> Send for CannotBeNameOfMacro<'a>

impl<'a> Send for ExpectedParenOrBrace<'a>

impl<'a> Send for FeatureRemoved<'a>

impl<'a> Send for FeatureRemovedReason<'a>

impl<'a> Send for RecursionLimitReached<'a>

impl<'a> Send for MacroState<'a>

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

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

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

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

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

impl<'feat> Send for ExpansionConfig<'feat>

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

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

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

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

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

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

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

impl Send for GateIssue

impl Send for Stability

impl Send for Feature

impl Send for Features

impl Send for LinkOrCopy

impl Send for Style

impl<'a> Send for LabelText<'a>

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

impl Send for CtorKind

impl Send for CtorOf

impl Send for DefKind

impl Send for LifetimeRes

impl Send for Namespace

impl Send for DefPathData

impl Send for ClosureKind

impl Send for Constness

impl Send for Defaultness

impl Send for IsAsync

impl Send for LocalSource

impl Send for LoopIdError

impl Send for LoopSource

impl Send for MatchSource

impl Send for ParamName

impl Send for PrimTy

impl Send for RangeEnd

impl Send for RpitContext

impl Send for Safety

impl Send for UseKind

impl Send for YieldSource

impl Send for LangItem

impl Send for MethodKind

impl Send for Target

impl Send for PartialRes

impl Send for Config

impl Send for DefKey

impl Send for DefPath

impl Send for Definitions

impl Send for AnonConst

impl Send for BodyId

impl Send for ConstBlock

impl Send for Destination

impl Send for DotDotPos

impl Send for FnHeader

impl Send for ImplItemId

impl Send for ImplItemRef

impl Send for InferArg

impl Send for ItemId

impl Send for Lifetime

impl Send for ModSpans

impl Send for TraitItemId

impl Send for Upvar

impl Send for HirId

impl Send for ItemLocalId

impl Send for OwnerId

impl Send for None

impl<'a> Send for FnKind<'a>

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

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

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

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

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

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

impl<'hir> Send for ArrayLen<'hir>

impl<'hir> Send for AssocItemConstraintKind<'hir>

impl<'hir> Send for ConstArgKind<'hir>

impl<'hir> Send for ExprKind<'hir>

impl<'hir> Send for FnRetTy<'hir>

impl<'hir> Send for ForeignItemKind<'hir>

impl<'hir> Send for GenericArg<'hir>

impl<'hir> Send for GenericBound<'hir>

impl<'hir> Send for GenericParamKind<'hir>

impl<'hir> Send for ImplItemKind<'hir>

impl<'hir> Send for InlineAsmOperand<'hir>

impl<'hir> Send for PatKind<'hir>

impl<'hir> Send for PreciseCapturingArg<'hir>

impl<'hir> Send for QPath<'hir>

impl<'hir> Send for StmtKind<'hir>

impl<'hir> Send for Term<'hir>

impl<'hir> Send for TraitFn<'hir>

impl<'hir> Send for TraitItemKind<'hir>

impl<'hir> Send for TyKind<'hir>

impl<'hir> Send for VariantData<'hir>

impl<'hir> Send for WherePredicate<'hir>

impl<'hir> Send for Arm<'hir>

impl<'hir> Send for AssocItemConstraint<'hir>

impl<'hir> Send for BareFnTy<'hir>

impl<'hir> Send for Block<'hir>

impl<'hir> Send for Body<'hir>

impl<'hir> Send for Closure<'hir>

impl<'hir> Send for ConstArg<'hir>

impl<'hir> Send for EnumDef<'hir>

impl<'hir> Send for Expr<'hir>

impl<'hir> Send for ExprField<'hir>

impl<'hir> Send for FieldDef<'hir>

impl<'hir> Send for FnDecl<'hir>

impl<'hir> Send for FnSig<'hir>

impl<'hir> Send for ForeignItem<'hir>

impl<'hir> Send for GenericArgs<'hir>

impl<'hir> Send for GenericParam<'hir>

impl<'hir> Send for Generics<'hir>

impl<'hir> Send for Impl<'hir>

impl<'hir> Send for ImplItem<'hir>

impl<'hir> Send for InlineAsm<'hir>

impl<'hir> Send for LetExpr<'hir>

impl<'hir> Send for LetStmt<'hir>

impl<'hir> Send for Mod<'hir>

impl<'hir> Send for MutTy<'hir>

impl<'hir> Send for OpaqueTy<'hir>

impl<'hir> Send for Param<'hir>

impl<'hir> Send for Pat<'hir>

impl<'hir> Send for PatField<'hir>

impl<'hir> Send for PathSegment<'hir>

impl<'hir> Send for PolyTraitRef<'hir>

impl<'hir> Send for Stmt<'hir>

impl<'hir> Send for TraitItem<'hir>

impl<'hir> Send for TraitRef<'hir>

impl<'hir> Send for Ty<'hir>

impl<'hir> Send for Variant<'hir>

impl<'hir> Send for WhereBoundPredicate<'hir>

impl<'hir> Send for WhereEqPredicate<'hir>

impl<'hir> Send for WhereRegionPredicate<'hir>

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

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

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

impl<'tcx> !Send for OwnerNodes<'tcx>

impl<'tcx> !Send for ParentedNode<'tcx>

impl<'tcx> !Send for Arena<'tcx>

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

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

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

impl Send for FnKind

impl Send for Context

impl Send for RegionId

impl Send for NamedVarMap

impl Send for NestedSpan

impl Send for Parameter

impl Send for WildPatTy

impl Send for InherentDyn

impl Send for LinkageType

impl Send for StartAsync

impl Send for TyParamSome

impl Send for VariancesOf

impl Send for CurrentItem

impl<'a> Send for Scope<'a>

impl<'a> Send for AssocItemNotFoundLabel<'a>

impl<'a> Send for AssocItemNotFoundSugg<'a>

impl<'a> Send for RegionInferReason<'a>

impl<'a> Send for VarianceTerm<'a>

impl<'a> Send for CollectUsageSpans<'a>

impl<'a> Send for TruncatedScopeDebug<'a>

impl<'a> Send for AmbiguousAssocItem<'a>

impl<'a> Send for AssocItemNotFound<'a>

impl<'a> Send for CoerceUnsizedMay<'a>

impl<'a> Send for CoerceUnsizedOneField<'a>

impl<'a> Send for CrossCrateTraits<'a>

impl<'a> Send for DispatchFromDynCoercion<'a>

impl<'a> Send for DispatchFromDynSame<'a>

impl<'a> Send for DispatchFromDynSingle<'a>

impl<'a> Send for DispatchFromDynStruct<'a>

impl<'a> Send for DispatchFromDynZST<'a>

impl<'a> Send for InherentPrimitiveTy<'a>

impl<'a> Send for InherentPrimitiveTyNote<'a>

impl<'a> Send for OnlyCurrentTraitsName<'a>

impl<'a> Send for OnlyCurrentTraitsTy<'a>

impl<'a> Send for TraitsWithDefaultImpl<'a>

impl<'a> Send for TransparentNonZeroSized<'a>

impl<'a> Send for UnsupportedDelegation<'a>

impl<'a> Send for Constraint<'a>

impl<'a, 'tcx> !Send for Autoderef<'a, 'tcx>

impl<'a, 'tcx> !Send for RemapLateBound<'a, 'tcx>

impl<'a, 'tcx> !Send for InlineAsmCtxt<'a, 'tcx>

impl<'a, 'tcx> !Send for WfCheckingCtxt<'a, 'tcx>

impl<'a, 'tcx> !Send for BoundVarContext<'a, 'tcx>

impl<'a, 'tcx> !Send for WrongNumberOfGenericArgs<'a, 'tcx>

impl<'a, 'tcx> !Send for GenericParamAndBoundVarCollector<'a, 'tcx>

impl<'a, 'tcx> !Send for ConstraintContext<'a, 'tcx>

impl<'a, 'tcx> !Send for SolveContext<'a, 'tcx>

impl<'a, 'tcx> !Send for TermsContext<'a, 'tcx>

impl<'a, 'tcx, E> !Send for ImplTraitInTraitCollector<'a, 'tcx, E>

impl<'cx, 'tcx> !Send for TyVarReplacer<'cx, 'tcx>

impl<'cx, 'tcx> !Send for UncoveredTyParamCollector<'cx, 'tcx>

impl<'tcx> !Send for Anonymize<'tcx>

impl<'tcx> !Send for ImplTraitInTraitCollector<'tcx>

impl<'tcx> !Send for RemapHiddenTyRegions<'tcx>

impl<'tcx> !Send for ReplaceTy<'tcx>

impl<'tcx> !Send for RegionResolutionVisitor<'tcx>

impl<'tcx> !Send for HasErrorDeep<'tcx>

impl<'tcx> !Send for IsProbablyCyclical<'tcx>

impl<'tcx> !Send for Checker<'tcx>

impl<'tcx> !Send for InherentCollect<'tcx>

impl<'tcx> !Send for InherentOverlapChecker<'tcx>

impl<'tcx> !Send for AssocTyToOpaque<'tcx>

impl<'tcx> !Send for MapAndCompressBoundVars<'tcx>

impl<'tcx> !Send for CollectItemTypesVisitor<'tcx>

impl<'tcx> !Send for FieldUniquenessCheckContext<'tcx>

impl<'tcx> !Send for ItemCtxt<'tcx>

impl<'tcx> !Send for RpitConstraintChecker<'tcx>

impl<'tcx> !Send for TaitConstraintLocator<'tcx>

impl<'tcx> !Send for GenericArgsBuilder<'tcx>

impl<'tcx> !Send for GenericsBuilder<'tcx>

impl<'tcx> !Send for ParamIndexRemapper<'tcx>

impl<'tcx> !Send for PredicatesBuilder<'tcx>

impl<'tcx> !Send for ExplicitPredicatesMap<'tcx>

impl<'tcx> Send for GenericsArgsErrExtend<'tcx>

impl<'tcx> Send for AutoderefSnapshot<'tcx>

impl<'tcx> Send for Bounds<'tcx>

impl<'tcx> Send for GATArgsCollector<'tcx>

impl<'tcx> Send for RedundantLifetimeArgsLint<'tcx>

impl<'tcx> Send for InvalidReceiverTy<'tcx>

impl<'tcx> Send for ParamInTyOfAssocConstBinding<'tcx>

impl<'tcx> Send for ReturnTypeNotationOnNonRpitit<'tcx>

impl<'tcx> Send for TyOfAssocConstBindingNote<'tcx>

impl<'tcx> Send for TyParamFirstLocal<'tcx>

impl<'tcx> Send for TyParamFirstLocalLint<'tcx>

impl<'tcx> Send for TypeOf<'tcx>

impl<'tcx> Send for TypeofReservedKeywordUsed<'tcx>

impl Send for Nested

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

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

impl Send for Diverges

impl Send for Needs

impl Send for PlaceOp

impl Send for Issue

impl Send for Mode

impl Send for ProbeResult

impl Send for ProbeScope

impl Send for IsAssign

impl Send for Op

impl Send for AdjustMode

impl Send for MutblCap

impl Send for UseIsEmpty

impl Send for ExpectedIdx

impl Send for ProvidedIdx

impl Send for TraitInfo

impl<'a> Send for DeclOrigin<'a>

impl<'a> Send for SelfSource<'a>

impl<'a> Send for ConstSelectMustBeFn<'a>

impl<'a> Send for Declaration<'a>

impl<'a, 'tcx> !Send for Coerce<'a, 'tcx>

impl<'a, 'tcx> !Send for NestedObligationsForSelfTy<'a, 'tcx>

impl<'a, 'tcx> !Send for FnCtxt<'a, 'tcx>

impl<'a, 'tcx> !Send for GatherLocalsVisitor<'a, 'tcx>

impl<'a, 'tcx> !Send for ConfirmContext<'a, 'tcx>

impl<'a, 'tcx> !Send for ProbeContext<'a, 'tcx>

impl<'a, 'tcx> !Send for InferBorrowKindVisitor<'a, 'tcx>

impl<'a, 'tcx> Send for PassToVariadicFunction<'a, 'tcx>

impl<'a, 'tcx> Send for PatInfo<'a, 'tcx>

impl<'cx, 'tcx> !Send for Resolver<'cx, 'tcx>

impl<'cx, 'tcx> !Send for WritebackCx<'cx, 'tcx>

impl<'tcx> !Send for FindClosureArg<'tcx>

impl<'tcx> !Send for TypeckRootCtxt<'tcx>

impl<'tcx> !Send for EagerlyNormalizeConsts<'tcx>

impl<'tcx> Send for CallStep<'tcx>

impl<'tcx> Send for CastError<'tcx>

impl<'tcx> Send for PointerKind<'tcx>

impl<'tcx> Send for TypeMismatchSource<'tcx>

impl<'tcx> Send for ExpectedReturnTypeLabel<'tcx>

impl<'tcx> Send for Expectation<'tcx>

impl<'tcx> Send for Compatibility<'tcx>

impl<'tcx> Send for Error<'tcx>

impl<'tcx> Send for MethodError<'tcx>

impl<'tcx> Send for CandidateKind<'tcx>

impl<'tcx> Send for PickKind<'tcx>

impl<'tcx> Send for DeferredCallResolution<'tcx>

impl<'tcx> Send for CastCheck<'tcx>

impl<'tcx> Send for ClosureSignatures<'tcx>

impl<'tcx> Send for ExpectedSig<'tcx>

impl<'tcx> Send for CannotCastToBool<'tcx>

impl<'tcx> Send for CastEnumDrop<'tcx>

impl<'tcx> Send for CastThinPointerToWidePointer<'tcx>

impl<'tcx> Send for IntToWide<'tcx>

impl<'tcx> Send for LossyProvenanceInt2Ptr<'tcx>

impl<'tcx> Send for LossyProvenancePtr2Int<'tcx>

impl<'tcx> Send for NoteCallerChoosesTyForTyParam<'tcx>

impl<'tcx> Send for SuggestConvertViaMethod<'tcx>

impl<'tcx> Send for TrivialCast<'tcx>

impl<'tcx> Send for ArgMatrix<'tcx>

impl<'tcx> Send for LoweredTy<'tcx>

impl<'tcx> Send for ConfirmResult<'tcx>

impl<'tcx> Send for Candidate<'tcx>

impl<'tcx> Send for Pick<'tcx>

impl<'tcx> Send for MethodCallee<'tcx>

impl<'tcx> Send for NoMatchData<'tcx>

impl<'tcx> Send for TopInfo<'tcx>

impl<'tcx> Send for BreakableCtxt<'tcx>

impl<'tcx> Send for CoroutineTypes<'tcx>

impl<'tcx> Send for EnclosingBreakables<'tcx>

impl<'tcx> Send for InferBorrowKind<'tcx>

impl<'tcx, 'exprs, E> Send for Expressions<'tcx, 'exprs, E>
where E: Sync,

impl<'tcx, 'exprs, E> Send for CoerceMany<'tcx, 'exprs, E>
where E: Sync,

impl<'tcx, Cx, D> Send for ExprUseVisitor<'tcx, Cx, D>
where Cx: Send, D: Send,

impl Send for NoCfg

impl Send for NoPath

impl Send for Ok

impl Send for UnknownItem

impl Send for Assertion

impl<'a> Send for AssertionAuto<'a>

impl<'a> Send for CopyWorkProductToCache<'a>

impl<'a> Send for CorruptFile<'a>

impl<'a> Send for CreateDepGraph<'a>

impl<'a> Send for CreateIncrCompDir<'a>

impl<'a> Send for CreateLock<'a>

impl<'a> Send for CreateNew<'a>

impl<'a> Send for DeleteFull<'a>

impl<'a> Send for DeleteLock<'a>

impl<'a> Send for DeleteOld<'a>

impl<'a> Send for DeletePartial<'a>

impl<'a> Send for DeleteWorkProduct<'a>

impl<'a> Send for Finalize<'a>

impl<'a> Send for FinalizedGcFailed<'a>

impl<'a> Send for HardLinkFailed<'a>

impl<'a> Send for InvalidGcFailed<'a>

impl<'a> Send for MoveDepGraph<'a>

impl<'a> Send for NotClean<'a>

impl<'a> Send for NotDirty<'a>

impl<'a> Send for NotLoaded<'a>

impl<'a> Send for RepeatedDepNodeLabel<'a>

impl<'a> Send for SessionGcFailed<'a>

impl<'a> Send for WriteNew<'a>

impl<'tcx> !Send for IfThisChanged<'tcx>

impl<'tcx> !Send for DirtyCleanVisitor<'tcx>

impl<'tcx> !Send for FindAllAttrs<'tcx>

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

impl Send for FixupError

impl<'a, 'tcx> !Send for At<'a, 'tcx>

impl<'a, 'tcx> !Send for RegionRelations<'a, 'tcx>

impl<'a, 'tcx> !Send for TypeFreshener<'a, 'tcx>

impl<'a, 'tcx> !Send for LeakCheck<'a, 'tcx>

impl<'a, 'tcx> !Send for FullTypeResolver<'a, 'tcx>

impl<'a, 'tcx> !Send for OpportunisticRegionResolver<'a, 'tcx>

impl<'a, 'tcx> !Send for OpportunisticVarResolver<'a, 'tcx>

impl<'a, 'tcx> !Send for InferenceFudger<'a, 'tcx>

impl<'a, 'tcx> Send for OpaqueTypeTable<'a, 'tcx>

impl<'a, 'tcx> Send for RegionConstraintCollector<'a, 'tcx>

impl<'a, 'tcx> Send for TypeVariableTable<'a, 'tcx>

impl<'a, 'tcx> Send for ProjectionCache<'a, 'tcx>

impl<'cx, 'tcx> !Send for Canonicalizer<'cx, 'tcx>

impl<'cx, 'tcx> !Send for LexicalResolver<'cx, 'tcx>

impl<'cx, 'tcx> !Send for VerifyBoundCx<'cx, 'tcx>

impl<'cx, 'tcx, D> !Send for TypeOutlives<'cx, 'tcx, D>

impl<'infcx, 'tcx> !Send for LatticeOp<'infcx, 'tcx>

impl<'infcx, 'tcx> !Send for TypeRelating<'infcx, 'tcx>

impl<'me, 'tcx> !Send for Generalizer<'me, 'tcx>

impl<'tcx> !Send for InferCtxt<'tcx>

impl<'tcx> !Send for InferCtxtBuilder<'tcx>

impl<'tcx> !Send for InferenceLiteralEraser<'tcx>

impl<'tcx> !Send for PredicateSet<'tcx>

impl<'tcx> Send for SubregionOrigin<'tcx>

impl<'tcx> Send for ValuePairs<'tcx>

impl<'tcx> Send for RegionResolutionError<'tcx>

impl<'tcx> Send for VarValue<'tcx>

impl<'tcx> Send for Constraint<'tcx>

impl<'tcx> Send for GenericKind<'tcx>

impl<'tcx> Send for UndoLog<'tcx>

impl<'tcx> Send for VerifyBound<'tcx>

impl<'tcx> Send for UndoLog<'tcx>

impl<'tcx> Send for TypeVariableValue<'tcx>

impl<'tcx> Send for ScrubbedTraitError<'tcx>

impl<'tcx> Send for ProjectionCacheEntry<'tcx>

impl<'tcx> Send for FreeRegionMap<'tcx>

impl<'tcx> Send for LexicalRegionResolutions<'tcx>

impl<'tcx> Send for RegionAndOrigin<'tcx>

impl<'tcx> Send for OpaqueTypeDecl<'tcx>

impl<'tcx> Send for OpaqueTypeStorage<'tcx>

impl<'tcx> Send for OutlivesEnvironment<'tcx>

impl<'tcx> Send for MiniGraph<'tcx>

impl<'tcx> Send for SccUniverse<'tcx>

impl<'tcx> Send for RegionConstraintData<'tcx>

impl<'tcx> Send for RegionConstraintStorage<'tcx>

impl<'tcx> Send for TwoRegions<'tcx>

impl<'tcx> Send for Verify<'tcx>

impl<'tcx> Send for VerifyIfEq<'tcx>

impl<'tcx> Send for CombinedSnapshot<'tcx>

impl<'tcx> Send for InferCtxtUndoLogs<'tcx>

impl<'tcx> Send for Snapshot<'tcx>

impl<'tcx> Send for InferCtxtInner<'tcx>

impl<'tcx> Send for RegionObligation<'tcx>

impl<'tcx> Send for TypeTrace<'tcx>

impl<'tcx> Send for TyVidEqKey<'tcx>

impl<'tcx> Send for TypeVariableStorage<'tcx>

impl<'tcx> Send for MismatchedProjectionTypes<'tcx>

impl<'tcx> Send for ProjectionCacheKey<'tcx>

impl<'tcx> Send for ProjectionCacheStorage<'tcx>

impl<'tcx, OP> !Send for ConstrainOpaqueTypeRegionVisitor<'tcx, OP>

impl<'tcx, OP> !Send for FreeRegionsVisitor<'tcx, OP>

impl<'tcx, T> Send for InferOk<'tcx, T>
where T: Send,

impl<'tcx, T> Send for Normalized<'tcx, T>
where T: Send,

impl<'tcx, T> Send for Obligation<'tcx, T>
where T: Send,

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

impl !Send for Compiler

impl !Send for Linker

impl Send for CantEmitMIR

impl Send for OutDirError

impl Send for Config

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

impl<'a> Send for FailedWritingFile<'a>

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

impl<'tcx> !Send for Queries<'tcx>

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

impl Send for Base

impl Send for DocStyle

impl Send for LiteralKind

impl Send for RawStrError

impl Send for TokenKind

impl Send for EscapeError

impl Send for MixedUnit

impl Send for Mode

impl Send for GuardedStr

impl Send for Token

impl<'a> Send for Cursor<'a>

impl !Send for LintStore

impl Send for TargetLint

impl Send for SymbolName

impl Send for ParamKind

impl Send for MutRefSugg

impl Send for CargoHelp

impl Send for PatternKind

impl Send for CItemKind

impl Send for AsmLabels

impl Send for InitError

impl Send for MissingDoc

impl Send for SoftLints

impl Send for UnderMacro

impl Send for UnsafeCode

impl Send for WhileTrue

impl Send for LintAlias

impl Send for LintGroup

impl Send for AltHead

impl Send for Diagnostics

impl Send for TyTyKind

impl Send for TypeIr

impl Send for BuilderPush

impl Send for LintSet

impl Send for TopDown

impl Send for Expectation

impl Send for MissingAbi

impl Send for RawPrefix

impl Send for TyQualified

impl Send for TykindDiag

impl Send for TykindKind

impl Send for UnknownLint

impl Send for UnusedLabel

impl Send for WasmCAbi

impl Send for Expr2024

impl Send for MapUnitFn

impl Send for NonPanicFmt

impl Send for PassByValue

impl Send for Precedence

impl Send for TypeLimits

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

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

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

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

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

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

impl<'a> Send for CheckLintNameResult<'a>

impl<'a> Send for OverflowingBinHexSub<'a>

impl<'a> Send for PtrNullChecksDiag<'a>

impl<'a> Send for RenamedLintSuggestion<'a>

impl<'a> Send for UseInclusiveRange<'a>

impl<'a> Send for CheckNameUnknownTool<'a>

impl<'a> Send for OverruledAttribute<'a>

impl<'a> Send for RequestedLevel<'a>

impl<'a> Send for BadOptAccessDiag<'a>

impl<'a> Send for BuiltinAnonymousParams<'a>

impl<'a> Send for BuiltinMissingDoc<'a>

impl<'a> Send for BuiltinTrivialBounds<'a>

impl<'a> Send for BuiltinUnreachablePub<'a>

impl<'a> Send for BuiltinUnusedDocComment<'a>

impl<'a> Send for DefaultHashTypesDiag<'a>

impl<'a> Send for DeprecatedLintName<'a>

impl<'a> Send for DropCopyDiag<'a>

impl<'a> Send for DropRefDiag<'a>

impl<'a> Send for ForgetCopyDiag<'a>

impl<'a> Send for ForgetRefDiag<'a>

impl<'a> Send for ImproperCTypes<'a>

impl<'a> Send for NonCamelCaseType<'a>

impl<'a> Send for NonSnakeCaseDiag<'a>

impl<'a> Send for NonUpperCaseGlobal<'a>

impl<'a> Send for NoopMethodCallDiag<'a>

impl<'a> Send for OverflowingBinHex<'a>

impl<'a> Send for OverflowingInt<'a>

impl<'a> Send for OverflowingIntHelp<'a>

impl<'a> Send for OverflowingLiteral<'a>

impl<'a> Send for OverflowingUInt<'a>

impl<'a> Send for OverruledAttributeLint<'a>

impl<'a> Send for RangeEndpointOutOfRange<'a>

impl<'a> Send for RefOfMutStatic<'a>

impl<'a> Send for RemovedLint<'a>

impl<'a> Send for RenamedLint<'a>

impl<'a> Send for SupertraitAsDerefTarget<'a>

impl<'a> Send for UnusedClosure<'a>

impl<'a> Send for UnusedCoroutine<'a>

impl<'a> Send for UnusedDelim<'a>

impl<'a> Send for UnusedOp<'a>

impl<'a> Send for UnusedResult<'a>

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

impl<'a, 'tcx> !Send for RuntimeCombinedLateLintPass<'a, 'tcx>

impl<'a, 'tcx> !Send for LintTailExpr<'a, 'tcx>

impl<'a, 'tcx> !Send for LintVisitor<'a, 'tcx>

impl<'a, 'tcx> !Send for LocalCollector<'a, 'tcx>

impl<'a, 'tcx> !Send for ImproperCTypesVisitor<'a, 'tcx>

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

impl<'hir> Send for BuiltinTypeAliasBounds<'hir>

impl<'lcx, 'tcx> !Send for DanglingPointerSearcher<'lcx, 'tcx>

impl<'s, P> !Send for LintLevelsBuilder<'s, P>

impl<'tcx> !Send for LateContext<'tcx>

impl<'tcx> !Send for FunctionalVariances<'tcx>

impl<'tcx> !Send for LintLevelMaximum<'tcx>

impl<'tcx> !Send for LintLevelQueryMap<'tcx>

impl<'tcx> Send for InvalidReferenceCastingDiag<'tcx>

impl<'tcx> Send for FfiResult<'tcx>

impl<'tcx> Send for ImplTraitOvercapturesLint<'tcx>

impl<'tcx> Send for PathCollector<'tcx>

impl<'tcx> Send for AddBound<'tcx>

impl<'tcx> Send for OpaqueHiddenInferredBoundLint<'tcx>

impl<'tcx> Send for CTypesVisitorState<'tcx>

impl<'tcx, 'a> !Send for FindSignificantDropper<'tcx, 'a>

impl<'tcx, T> !Send for LateContextAndPass<'tcx, T>

impl<'tcx, VarFn, OutlivesFn> !Send for VisitOpaqueTypes<'tcx, VarFn, OutlivesFn>

impl Send for Level

impl Send for Lint

impl Send for LintBuffer

impl Send for LintId

impl Send for RustString

impl Send for Error

impl !Send for LoadedMacro

impl !Send for CStore

impl Send for DylibError

impl Send for LoadResult

impl Send for CrateError

impl Send for CrateFlavor

impl Send for LazyState

impl Send for SpanKind

impl Send for Library

impl Send for DlError

impl Send for LinkCfgForm

impl Send for CratePaths

impl Send for AttrFlags

impl Send for CrateDep

impl Send for CrateHeader

impl Send for CrateRoot

impl Send for LazyTables

impl Send for RawDefId

impl Send for SpanTag

impl Send for TraitImpls

impl Send for VariantData

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

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

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

impl<'a> Send for MetadataError<'a>

impl<'a> Send for EmptyRenamingTarget<'a>

impl<'a> Send for ExternLocationNotExist<'a>

impl<'a> Send for ExternLocationNotFile<'a>

impl<'a> Send for FailWriteFile<'a>

impl<'a> Send for FailedCreateFile<'a>

impl<'a> Send for LibFilenameForm<'a>

impl<'a> Send for LibRequired<'a>

impl<'a> Send for MissingNativeLibrary<'a>

impl<'a> Send for MultipleModifiers<'a>

impl<'a> Send for MultipleRenamings<'a>

impl<'a> Send for NoCrateWithTriple<'a>

impl<'a> Send for NoTransitiveNeedsDep<'a>

impl<'a> Send for RenamingNoLink<'a>

impl<'a> Send for RustcLibRequired<'a>

impl<'a> Send for SuggestLibraryName<'a>

impl<'a> Send for UnknownImportNameType<'a>

impl<'a> Send for UnknownLinkKind<'a>

impl<'a> Send for UnknownLinkModifier<'a>

impl<'a> Send for AnalyzeAttrState<'a>

impl<'a, 'tcx> !Send for CrateLoader<'a, 'tcx>

impl<'a, 'tcx> !Send for DecodeContext<'a, 'tcx>

impl<'a, 'tcx> !Send for EncodeContext<'a, 'tcx>

impl<'a, 'tcx, T> !Send for DecodeIterator<'a, 'tcx, T>

impl<'tcx> !Send for Collector<'tcx>

impl<'tcx> Send for DefPathHashMapRef<'tcx>

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

impl<I, T> Send for TableBuilder<I, T>
where <T as FixedSizeEncoding>::ByteArray: Send, T: Send,

impl<T> Send for LazyArray<T>

impl<T> Send for LazyValue<T>

impl !Send for CurrentGcx

impl Send for DepKindDefs

impl Send for PlaceBase

impl Send for Certainty

impl Send for Reexport

impl Send for Linkage

impl Send for Level

impl Send for ScopeData

impl Send for ResolvedArg

impl Send for EvalResult

impl Send for CovTerm

impl Send for MappingKind

impl Send for Op

impl Send for DefLocation

impl Send for LocalKind

impl Send for AllocError

impl Send for InitChunk

impl Send for State

impl Send for PointerKind

impl Send for Linkage

impl Send for Visibility

impl Send for PassWhere

impl Send for BinOp

impl Send for BorrowKind

impl Send for CallSource

impl Send for CastKind

impl Send for MirPhase

impl Send for RetagKind

impl Send for UnOp

impl Send for TyContext

impl Send for BlockSafety

impl Send for LintLevel

impl Send for LogicalOp

impl Send for IsConstable

impl Send for Node

impl Send for OverlapMode

impl Send for CastKind

impl Send for AdtKind

impl Send for AssocKind

impl Send for CastKind

impl Send for IntTy

impl Send for BorrowKind

impl Send for FeedConstTy

impl Send for ExprKind

impl Send for Asyncness

impl Send for ParamTerm

impl Send for TermVid

impl Send for ReifyReason

impl Send for BoundTyKind

impl Send for DepsType

impl Send for All

impl Send for OnlyBodies

impl Send for ModuleItems

impl Send for Providers

impl Send for ModChild

impl Send for LibFeatures

impl Send for Scope

impl Send for ScopeTree

impl Send for YieldData

impl Send for Deprecated

impl Send for Index

impl Send for Cache

impl Send for BranchSpan

impl Send for ConditionId

impl Send for CounterId

impl Send for Expression

impl Send for Mapping

impl Send for InitCopy

impl Send for InitMask

impl Send for AllocRange

impl Send for Guard

impl Send for AllocId

impl Send for BasicBlock

impl Send for Local

impl Send for Location

impl Send for Promoted

impl Send for SourceInfo

impl Send for SourceScope

impl Send for LocalCrate

impl Send for Footer

impl Send for Providers

impl Send for QueryEngine

impl Send for ArmId

impl Send for Block

impl Send for BlockId

impl Send for ExprId

impl Send for FieldExpr

impl Send for LocalVarId

impl Send for ParamId

impl Send for StmtId

impl Send for Children

impl Send for Graph

impl Send for LeafDef

impl Send for AdtDefData

impl Send for AdtFlags

impl Send for AssocItem

impl Send for AssocItems

impl Send for CaptureInfo

impl Send for UpvarId

impl Send for UpvarPath

impl Send for ConstInt

impl Send for ScalarInt

impl Send for Generics

impl Send for TypeInfo

impl Send for BoundRegion

impl Send for Destructor

impl Send for FieldDef

impl Send for ParamTag

impl Send for VariantDef

impl Send for BoundTy

impl Send for ParamConst

impl Send for ParamTy

impl Send for TraitDef

impl Send for TraitImpls

impl Send for MaxUniverse

impl Send for Providers

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

impl<'a> Send for LimitInvalid<'a>

impl<'a> Send for InitChunkIter<'a>

impl<'a> Send for SwitchTargetsIter<'a>

impl<'a> Send for LocalSetInContext<'a>

impl<'a> Send for LocalSetInContextMut<'a>

impl<'a, 'tcx> !Send for MonoReachable<'a, 'tcx>

impl<'a, 'tcx> !Send for CacheDecoder<'a, 'tcx>

impl<'a, 'tcx> !Send for CacheEncoder<'a, 'tcx>

impl<'a, 'tcx> !Send for FnMutDelegate<'a, 'tcx>

impl<'a, 'tcx> !Send for RegionFolder<'a, 'tcx>

impl<'a, 'tcx> !Send for FmtPrinter<'a, 'tcx>

impl<'a, 'tcx> !Send for FmtPrinterData<'a, 'tcx>

impl<'a, 'tcx> !Send for RegionFolder<'a, 'tcx>

impl<'a, 'tcx> !Send for ImplicitCtxt<'a, 'tcx>

impl<'a, 'tcx> Send for CallReturnPlaces<'a, 'tcx>

impl<'a, 'tcx> Send for Preorder<'a, 'tcx>

impl<'a, 'tcx, C> Send for Postorder<'a, 'tcx, C>
where C: Send,

impl<'a, G, NodeContentFn, EdgeLabelsFn> Send for GraphvizWriter<'a, G, NodeContentFn, EdgeLabelsFn>
where NodeContentFn: Send, EdgeLabelsFn: Send, G: Sync,

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

impl<'a, V> Send for LocalTableInContextMut<'a, V>
where V: Send,

impl<'hir> !Send for Map<'hir>

impl<'hir> !Send for ParentHirIterator<'hir>

impl<'hir> !Send for ParentOwnerIterator<'hir>

impl<'mir, 'tcx> Send for TerminatorEdges<'mir, 'tcx>

impl<'s> !Send for AllocDecodingSession<'s>

impl<'sess> !Send for OnDiskCache<'sess>

impl<'tcx> !Send for InterpErrorKind<'tcx>

impl<'tcx> !Send for UndefinedBehaviorInfo<'tcx>

impl<'tcx> !Send for Arena<'tcx>

impl<'tcx> !Send for ItemCollector<'tcx>

impl<'tcx> !Send for InterpErrorInfo<'tcx>

impl<'tcx> !Send for InterpErrorInfoInner<'tcx>

impl<'tcx> !Send for CodegenUnitNameBuilder<'tcx>

impl<'tcx> !Send for ExtraComments<'tcx>

impl<'tcx> !Send for QuerySystem<'tcx>

impl<'tcx> !Send for TyCtxtAt<'tcx>

impl<'tcx> !Send for TyCtxtEnsure<'tcx>

impl<'tcx> !Send for TyCtxtEnsureWithValue<'tcx>

impl<'tcx> !Send for QueryArenas<'tcx>

impl<'tcx> !Send for CtxtInterners<'tcx>

impl<'tcx> !Send for GlobalCtxt<'tcx>

impl<'tcx> !Send for TyCtxt<'tcx>

impl<'tcx> !Send for IsSuggestableVisitor<'tcx>

impl<'tcx> !Send for MakeSuggestableFolder<'tcx>

impl<'tcx> !Send for StaticLifetimeVisitor<'tcx>

impl<'tcx> !Send for TraitObjectVisitor<'tcx>

impl<'tcx> !Send for RegionEraserVisitor<'tcx>

impl<'tcx> !Send for LayoutCx<'tcx>

impl<'tcx> !Send for ReverseMapper<'tcx>

impl<'tcx> !Send for ImplTraitHeader<'tcx>

impl<'tcx> !Send for OpaqueTypeExpander<'tcx>

impl<'tcx> !Send for WeakAliasTypeExpander<'tcx>

impl<'tcx> Send for LayoutError<'tcx>

impl<'tcx> Send for ConstVariableValue<'tcx>

impl<'tcx> Send for RegionVariableValue<'tcx>

impl<'tcx> Send for ExportedSymbol<'tcx>

impl<'tcx> Send for Const<'tcx>

impl<'tcx> Send for ConstValue<'tcx>

impl<'tcx> Send for BindingForm<'tcx>

impl<'tcx> Send for LocalInfo<'tcx>

impl<'tcx> Send for MentionedItem<'tcx>

impl<'tcx> Send for VarDebugInfoContents<'tcx>

impl<'tcx> Send for GlobalAlloc<'tcx>

impl<'tcx> Send for InvalidProgramInfo<'tcx>

impl<'tcx> Send for ValidationErrorKind<'tcx>

impl<'tcx> Send for MonoItem<'tcx>

impl<'tcx> Send for ClosureOutlivesSubject<'tcx>

impl<'tcx> Send for ConstraintCategory<'tcx>

impl<'tcx> Send for AggregateKind<'tcx>

impl<'tcx> Send for InlineAsmOperand<'tcx>

impl<'tcx> Send for NonDivergingIntrinsic<'tcx>

impl<'tcx> Send for NullOp<'tcx>

impl<'tcx> Send for Operand<'tcx>

impl<'tcx> Send for Rvalue<'tcx>

impl<'tcx> Send for StatementKind<'tcx>

impl<'tcx> Send for TerminatorKind<'tcx>

impl<'tcx> Send for BodyTy<'tcx>

impl<'tcx> Send for ExprKind<'tcx>

impl<'tcx> Send for InlineAsmOperand<'tcx>

impl<'tcx> Send for PatKind<'tcx>

impl<'tcx> Send for PatRangeBoundary<'tcx>

impl<'tcx> Send for StmtKind<'tcx>

impl<'tcx> Send for ObligationCauseCode<'tcx>

impl<'tcx> Send for SelectionError<'tcx>

impl<'tcx> Send for OutlivesBound<'tcx>

impl<'tcx> Send for SelectionCandidate<'tcx>

impl<'tcx> Send for Adjust<'tcx>

impl<'tcx> Send for AutoBorrow<'tcx>

impl<'tcx> Send for CastTy<'tcx>

impl<'tcx> Send for ValTree<'tcx>

impl<'tcx> Send for ImplSubject<'tcx>

impl<'tcx> Send for InhabitedPredicate<'tcx>

impl<'tcx> Send for InstanceKind<'tcx>

impl<'tcx> Send for FnAbiError<'tcx>

impl<'tcx> Send for FnAbiRequest<'tcx>

impl<'tcx> Send for LayoutError<'tcx>

impl<'tcx> Send for SizeSkeleton<'tcx>

impl<'tcx> Send for NormalizationError<'tcx>

impl<'tcx> Send for PatternKind<'tcx>

impl<'tcx> Send for UpvarArgs<'tcx>

impl<'tcx> Send for UserType<'tcx>

impl<'tcx> Send for ExplicitSelf<'tcx>

impl<'tcx> Send for NotUniqueParam<'tcx>

impl<'tcx> Send for VtblEntry<'tcx>

impl<'tcx> Send for CallKind<'tcx>

impl<'tcx> Send for DropCheckOverflow<'tcx>

impl<'tcx> Send for OpaqueHiddenTypeMismatch<'tcx>

impl<'tcx> Send for RecursionLimitReached<'tcx>

impl<'tcx> Send for Place<'tcx>

impl<'tcx> Send for PlaceWithHirId<'tcx>

impl<'tcx> Send for Projection<'tcx>

impl<'tcx> Send for CanonicalParamEnvCache<'tcx>

impl<'tcx> Send for OriginalQueryValues<'tcx>

impl<'tcx> Send for QueryRegionConstraints<'tcx>

impl<'tcx> Send for MemberConstraint<'tcx>

impl<'tcx> Send for ConstVidKey<'tcx>

impl<'tcx> Send for RegionVidKey<'tcx>

impl<'tcx> Send for BasicBlocks<'tcx>

impl<'tcx> Send for ConstAlloc<'tcx>

impl<'tcx> Send for UnevaluatedConst<'tcx>

impl<'tcx> Send for ConstAllocation<'tcx>

impl<'tcx> Send for ValidationErrorInfo<'tcx>

impl<'tcx> Send for AllocMap<'tcx>

impl<'tcx> Send for GlobalId<'tcx>

impl<'tcx> Send for LitToConstInput<'tcx>

impl<'tcx> Send for CodegenUnit<'tcx>

impl<'tcx> Send for MirPatch<'tcx>

impl<'tcx> Send for BorrowCheckResult<'tcx>

impl<'tcx> Send for ClosureOutlivesRequirement<'tcx>

impl<'tcx> Send for ClosureOutlivesSubjectTy<'tcx>

impl<'tcx> Send for ClosureRegionRequirements<'tcx>

impl<'tcx> Send for CoroutineLayout<'tcx>

impl<'tcx> Send for CoroutineSavedTy<'tcx>

impl<'tcx> Send for DestructuredConstant<'tcx>

impl<'tcx> Send for PlaceRef<'tcx>

impl<'tcx> Send for Statement<'tcx>

impl<'tcx> Send for BasicBlockData<'tcx>

impl<'tcx> Send for Body<'tcx>

impl<'tcx> Send for CoroutineInfo<'tcx>

impl<'tcx> Send for LocalDecl<'tcx>

impl<'tcx> Send for MirSource<'tcx>

impl<'tcx> Send for SourceScopeData<'tcx>

impl<'tcx> Send for VarBindingForm<'tcx>

impl<'tcx> Send for VarDebugInfo<'tcx>

impl<'tcx> Send for VarDebugInfoFragment<'tcx>

impl<'tcx> Send for ConstOperand<'tcx>

impl<'tcx> Send for CopyNonOverlapping<'tcx>

impl<'tcx> Send for Place<'tcx>

impl<'tcx> Send for PlaceTy<'tcx>

impl<'tcx> Send for Terminator<'tcx>

impl<'tcx> Send for QuerySystemFns<'tcx>

impl<'tcx> Send for DynamicQueries<'tcx>

impl<'tcx> Send for QueryCaches<'tcx>

impl<'tcx> Send for QueryStates<'tcx>

impl<'tcx> Send for AdtExpr<'tcx>

impl<'tcx> Send for Arm<'tcx>

impl<'tcx> Send for Ascription<'tcx>

impl<'tcx> Send for ClosureExpr<'tcx>

impl<'tcx> Send for Expr<'tcx>

impl<'tcx> Send for FieldPat<'tcx>

impl<'tcx> Send for FruInfo<'tcx>

impl<'tcx> Send for InlineAsmExpr<'tcx>

impl<'tcx> Send for Param<'tcx>

impl<'tcx> Send for Pat<'tcx>

impl<'tcx> Send for PatRange<'tcx>

impl<'tcx> Send for Stmt<'tcx>

impl<'tcx> Send for Thir<'tcx>

impl<'tcx> Send for CandidateStep<'tcx>

impl<'tcx> Send for DropckConstraint<'tcx>

impl<'tcx> Send for DropckOutlivesResult<'tcx>

impl<'tcx> Send for MethodAutoderefBadTy<'tcx>

impl<'tcx> Send for MethodAutoderefStepsResult<'tcx>

impl<'tcx> Send for NormalizationResult<'tcx>

impl<'tcx> Send for AscribeUserType<'tcx>

impl<'tcx> Send for DropckOutlives<'tcx>

impl<'tcx> Send for Eq<'tcx>

impl<'tcx> Send for ImpliedOutlivesBounds<'tcx>

impl<'tcx> Send for ProvePredicate<'tcx>

impl<'tcx> Send for Subtype<'tcx>

impl<'tcx> Send for ExternalConstraints<'tcx>

impl<'tcx> Send for PredefinedOpaques<'tcx>

impl<'tcx> Send for Ancestors<'tcx>

impl<'tcx> Send for DerivedCause<'tcx>

impl<'tcx> Send for IfExpressionCause<'tcx>

impl<'tcx> Send for ImplDerivedCause<'tcx>

impl<'tcx> Send for InternedObligationCauseCode<'tcx>

impl<'tcx> Send for MatchExpressionArmCause<'tcx>

impl<'tcx> Send for ObligationCause<'tcx>

impl<'tcx> Send for SignatureMismatchData<'tcx>

impl<'tcx> Send for UnifyReceiverContext<'tcx>

impl<'tcx> Send for Adjustment<'tcx>

impl<'tcx> Send for OverloadedDeref<'tcx>

impl<'tcx> Send for AdtDef<'tcx>

impl<'tcx> Send for CapturedPlace<'tcx>

impl<'tcx> Send for ClosureTypeInfo<'tcx>

impl<'tcx> Send for Expr<'tcx>

impl<'tcx> Send for Const<'tcx>

impl<'tcx> Send for CommonConsts<'tcx>

impl<'tcx> Send for CommonLifetimes<'tcx>

impl<'tcx> Send for CommonTypes<'tcx>

impl<'tcx> Send for UserArgs<'tcx>

impl<'tcx> Send for UserSelfTy<'tcx>

impl<'tcx> Send for ConstConditions<'tcx>

impl<'tcx> Send for GenericPredicates<'tcx>

impl<'tcx> Send for Instance<'tcx>

impl<'tcx> Send for ShortInstance<'tcx>

impl<'tcx> Send for Pattern<'tcx>

impl<'tcx> Send for Clause<'tcx>

impl<'tcx> Send for Predicate<'tcx>

impl<'tcx> Send for OpaqueFnEntry<'tcx>

impl<'tcx> Send for PrintClosureAsImpl<'tcx>

impl<'tcx> Send for RegionHighlightMode<'tcx>

impl<'tcx> Send for TraitRefPrintOnlyTraitName<'tcx>

impl<'tcx> Send for TraitRefPrintOnlyTraitPath<'tcx>

impl<'tcx> Send for TraitRefPrintSugared<'tcx>

impl<'tcx> Send for Region<'tcx>

impl<'tcx> Send for BoundConst<'tcx>

impl<'tcx> Send for ClosureSizeProfileData<'tcx>

impl<'tcx> Send for CratePredicatesMap<'tcx>

impl<'tcx> Send for CrateVariancesMap<'tcx>

impl<'tcx> Send for DestructuredConst<'tcx>

impl<'tcx> Send for ImplHeader<'tcx>

impl<'tcx> Send for InstantiatedPredicates<'tcx>

impl<'tcx> Send for OpaqueHiddenType<'tcx>

impl<'tcx> Send for ParamEnv<'tcx>

impl<'tcx> Send for SymbolName<'tcx>

impl<'tcx> Send for Ty<'tcx>

impl<'tcx> Send for InlineConstArgs<'tcx>

impl<'tcx> Send for CanonicalUserTypeAnnotation<'tcx>

impl<'tcx> Send for TypeckResults<'tcx>

impl<'tcx> Send for Discr<'tcx>

impl<'tcx> Send for TypeWalker<'tcx>

impl<'tcx, C> Send for DynamicQuery<'tcx, C>
where C: Send, <C as QueryCache>::Key: Send,

impl<'tcx, D> !Send for BoundVarReplacer<'tcx, D>

impl<'tcx, F, G, H> !Send for BottomUpFolder<'tcx, F, G, H>

impl<'tcx, KEY> !Send for Feed<'tcx, KEY>

impl<'tcx, KEY> !Send for TyCtxtFeed<'tcx, KEY>

impl<'tcx, N> Send for ImplSource<'tcx, N>
where N: Send,

impl<'tcx, N> Send for ImplSourceUserDefinedData<'tcx, N>
where N: Send,

impl<'tcx, R> Send for QueryResponse<'tcx, R>
where R: Send,

impl<'tcx, T> !Send for InterpResult_<'tcx, T>

impl<'tcx, T> Send for InternedInSet<'tcx, T>
where T: Sync + ?Sized,

impl<'tcx, T> Send for ParamEnvAnd<'tcx, T>
where T: Send,

impl<'tcx, T> Send for InlineConstArgsParts<'tcx, T>
where T: Send,

impl<H, T> !Send for RawList<H, T>

impl<H, T> Send for ListSkeleton<H, T>
where H: Send, T: Send,

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

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

impl<O> Send for AssertKind<O>
where O: Send,

impl<Prov> Send for Scalar<Prov>
where Prov: Send,

impl<Prov> Send for ProvenanceCopy<Prov>
where Prov: Send,

impl<Prov> Send for ProvenanceMap<Prov>
where Prov: Send,

impl<Prov> Send for Pointer<Prov>
where Prov: Send,

impl<Prov, Extra, Bytes> Send for Allocation<Prov, Extra, Bytes>
where Bytes: Send, Extra: Send, Prov: Send,

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

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

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

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

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

impl<V, T> Send for ProjectionElem<V, T>
where T: Send, V: Send,

impl Send for BlockFrame

impl Send for ForGuard

impl Send for PlaceBase

impl Send for Category

impl Send for RvalueFunc

impl Send for DropKind

impl Send for Conflict

impl Send for SuggestLet

impl Send for LetSource

impl Send for MCDCState

impl Send for BranchInfo

impl Send for NotInfo

impl Send for ParseError

impl Send for ArmHasGuard

impl Send for DropData

impl Send for DropIdx

impl Send for DropNode

impl Send for DropNodeKey

impl Send for DropTree

impl Send for ExitScopes

impl Send for IfThenScope

impl Send for Scope

impl Send for Unwind

impl Send for GuardFrame

impl Send for ScopeId

impl Send for Inform

impl Send for NaNPattern

impl Send for Variant

impl<'a, 'b, 'tcx> !Send for FakeBorrowCollector<'a, 'b, 'tcx>

impl<'a, 'tcx> !Send for ParseCtxt<'a, 'tcx>

impl<'a, 'tcx> !Send for Builder<'a, 'tcx>

impl<'a, 'tcx> !Send for LayoutConstrainedPlaceVisitor<'a, 'tcx>

impl<'a, 'tcx> !Send for UnsafetyVisitor<'a, 'tcx>

impl<'a, 'tcx> !Send for PatCtxt<'a, 'tcx>

impl<'a, 'tcx> Send for ThirPrinter<'a, 'tcx>

impl<'mir, 'tcx, C> !Send for Search<'mir, 'tcx, C>

impl<'p, 'tcx> !Send for MatchVisitor<'p, 'tcx>

impl<'p, 'tcx, 'm> !Send for NonExhaustivePatternsTypeNotEmpty<'p, 'tcx, 'm>

impl<'pat, 'tcx> Send for TestCase<'pat, 'tcx>

impl<'pat, 'tcx> Send for Candidate<'pat, 'tcx>

impl<'pat, 'tcx> Send for FlatPat<'pat, 'tcx>

impl<'pat, 'tcx> Send for MatchPairTree<'pat, 'tcx>

impl<'s, 'tcx> Send for PatternNotCovered<'s, 'tcx>

impl<'tcx> !Send for Cx<'tcx>

impl<'tcx> !Send for ConstToPat<'tcx>

impl<'tcx> Send for TestBranch<'tcx>

impl<'tcx> Send for TestKind<'tcx>

impl<'tcx> Send for PlaceBuilder<'tcx>

impl<'tcx> Send for Ascription<'tcx>

impl<'tcx> Send for Binding<'tcx>

impl<'tcx> Send for BuiltMatchTree<'tcx>

impl<'tcx> Send for MatchTreeBranch<'tcx>

impl<'tcx> Send for MatchTreeSubBranch<'tcx>

impl<'tcx> Send for PatternExtraData<'tcx>

impl<'tcx> Send for Test<'tcx>

impl<'tcx> Send for BreakableScope<'tcx>

impl<'tcx> Send for Scopes<'tcx>

impl<'tcx> Send for CFG<'tcx>

impl<'tcx> Send for Capture<'tcx>

impl<'tcx> Send for AdtDefinedHere<'tcx>

impl<'tcx> Send for BorrowOfMovedValue<'tcx>

impl<'tcx> Send for InvalidPattern<'tcx>

impl<'tcx> Send for LiteralOutOfRange<'tcx>

impl<'tcx> Send for NonEmptyNeverPattern<'tcx>

impl<'tcx> Send for TypeNotPartialEq<'tcx>

impl<'tcx> Send for TypeNotStructural<'tcx>

impl<'tcx> Send for UnreachablePattern<'tcx>

impl<'tcx> Send for UnsizedPattern<'tcx>

impl<'tcx> Send for CallRecursion<'tcx>

impl<'tcx> Send for RecursiveDrop<'tcx>

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

impl Send for DropStyle

impl Send for Unwind

impl Send for Effect

impl Send for Background

impl Send for OutputStyle

impl Send for DefUse

impl Send for InitKind

impl Send for TrackElem

impl Send for Backward

impl Send for Forward

impl Send for CfgEdge

impl Send for EffectIndex

impl Send for Init

impl Send for InitIndex

impl Send for MoveOut

impl Send for PointIndex

impl Send for PeekCall

impl Send for PlaceIndex

impl Send for ValueIndex

impl<'a> Send for TransferFunction<'a>

impl<'a> Send for YieldResumeEffect<'a>

impl<'a> Send for MaybeStorageDead<'a>

impl<'a> Send for MaybeStorageLive<'a>

impl<'a, 'b, 'tcx, D> Send for DropCtxt<'a, 'b, 'tcx, D>
where <D as DropElaborator<'b, 'tcx>>::Path: Send, D: Send,

impl<'a, 'mir, 'tcx> Send for MoveVisitor<'a, 'mir, 'tcx>

impl<'a, 'tcx> !Send for MaybeInitializedPlaces<'a, 'tcx>

impl<'a, 'tcx> !Send for MaybeUninitializedPlaces<'a, 'tcx>

impl<'a, 'tcx> !Send for PlaceCollector<'a, 'tcx>

impl<'a, 'tcx> Send for DefinitelyInitializedPlaces<'a, 'tcx>

impl<'a, 'tcx> Send for EverInitializedPlaces<'a, 'tcx>

impl<'a, 'tcx> Send for ProjectionIter<'a, 'tcx>

impl<'a, 'tcx> Send for Children<'a, 'tcx>

impl<'a, 'tcx, F> !Send for MoveDataBuilder<'a, 'tcx, F>

impl<'a, 'tcx, F> Send for MovePathLinearIter<'a, 'tcx, F>
where F: Send,

impl<'a, N> Send for Visitor<'a, N>

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

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

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

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

impl<'mir, 'tcx> Send for MaybeRequiresStorage<'mir, 'tcx>

impl<'mir, 'tcx, A> Send for ResultsCursor<'mir, 'tcx, A>
where <A as Analysis<'tcx>>::Domain: Send, A: Send,

impl<'mir, 'tcx, A> Send for BlockFormatter<'mir, 'tcx, A>
where <A as Analysis<'tcx>>::Domain: Send, A: Send,

impl<'mir, 'tcx, A> Send for Formatter<'mir, 'tcx, A>
where A: Send, <A as Analysis<'tcx>>::Domain: Send,

impl<'mir, 'tcx, D, F> Send for BackwardSwitchIntEdgeEffectsApplier<'mir, 'tcx, D, F>
where D: Send, F: Send,

impl<'mir, D, F> Send for ForwardSwitchIntEdgeEffectsApplier<'mir, D, F>
where F: Send, D: Send,

impl<'tcx> Send for MoveData<'tcx>

impl<'tcx> Send for MovePath<'tcx>

impl<'tcx> Send for MovePathLookup<'tcx>

impl<'tcx> Send for MoveDataParamEnv<'tcx>

impl<'tcx> Send for UnDerefer<'tcx>

impl<'tcx> Send for Map<'tcx>

impl<'tcx> Send for PlaceInfo<'tcx>

impl<'tcx, A> Send for Results<'tcx, A>
where A: Send, <A as Analysis<'tcx>>::Domain: Send,

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

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

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

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

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

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

impl<V> Send for State<V>
where V: Send,

impl<V> Send for ValueOrPlace<V>
where V: Send,

impl<V> Send for StateData<V>
where V: Send,

impl Send for Operation

impl Send for BcbCounter

impl Send for ConstMutate

impl Send for AddressKind

impl Send for Polarity

impl Send for Update

impl Send for TempState

impl Send for Adjustment

impl Send for DerefSource

impl Send for SimplifyCfg

impl Send for EdgeKind

impl Send for AddRetag

impl Send for Subtyper

impl Send for CopyProp

impl Send for BranchPair

impl Send for CodeMapping

impl Send for MCDCBranch

impl Send for Hole

impl Send for SpanFromMir

impl Send for Covspan

impl Send for CtfeLimit

impl Send for Derefer

impl Send for Candidates

impl Send for WriteInfo

impl Send for Marker

impl Send for FnItemRef

impl Send for GVN

impl Send for VnIndex

impl Send for Inline

impl Send for Condition

impl Send for EnumSizeOpt

impl Send for LocalFinder

impl Send for Candidate

impl Send for RemoveZsts

impl Send for RevealAll

impl Send for SanityCheck

impl Send for UsedLocals

impl Send for SsaLocals

impl Send for Validator

impl<'a> Send for CoverageSuccessors<'a>

impl<'a> Send for SuspendCheckData<'a>

impl<'a> Send for CountersBuilder<'a>

impl<'a> Send for ConditionSet<'a>

impl<'a, 'b, 'tcx> !Send for OperandCollector<'a, 'b, 'tcx>

impl<'a, 'tcx> !Send for SubTypeChecker<'a, 'tcx>

impl<'a, 'tcx> !Send for PointerFinder<'a, 'tcx>

impl<'a, 'tcx> !Send for ConstMutationChecker<'a, 'tcx>

impl<'a, 'tcx> !Send for PackedRefChecker<'a, 'tcx>

impl<'a, 'tcx> !Send for UndefinedTransmutesChecker<'a, 'tcx>

impl<'a, 'tcx> !Send for Replacer<'a, 'tcx>

impl<'a, 'tcx> !Send for Collector<'a, 'tcx>

impl<'a, 'tcx> !Send for ConstAnalysis<'a, 'tcx>

impl<'a, 'tcx> !Send for DerefChecker<'a, 'tcx>

impl<'a, 'tcx> !Send for ElaborateBoxDerefVisitor<'a, 'tcx>

impl<'a, 'tcx> !Send for ElaborateDropsCtxt<'a, 'tcx>

impl<'a, 'tcx> !Send for InitializationData<'a, 'tcx>

impl<'a, 'tcx> !Send for MustNotSupend<'a, 'tcx>

impl<'a, 'tcx> !Send for FunctionItemRefChecker<'a, 'tcx>

impl<'a, 'tcx> !Send for Integrator<'a, 'tcx>

impl<'a, 'tcx> !Send for InstSimplifyContext<'a, 'tcx>

impl<'a, 'tcx> !Send for TOFinder<'a, 'tcx>

impl<'a, 'tcx> !Send for Lint<'a, 'tcx>

impl<'a, 'tcx> !Send for MentionedItemsVisitor<'a, 'tcx>

impl<'a, 'tcx> !Send for Collector<'a, 'tcx>

impl<'a, 'tcx> !Send for Promoter<'a, 'tcx>

impl<'a, 'tcx> !Send for Validator<'a, 'tcx>

impl<'a, 'tcx> !Send for Replacer<'a, 'tcx>

impl<'a, 'tcx> !Send for DropShimElaborator<'a, 'tcx>

impl<'a, 'tcx> !Send for CfgChecker<'a, 'tcx>

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

impl<'a, 'tcx> Send for ExpectedTransformKind<'a, 'tcx>

impl<'a, 'tcx> Send for AssignedValue<'a, 'tcx>

impl<'a, 'tcx> Send for StorageConflictVisitor<'a, 'tcx>

impl<'a, 'tcx> Send for BasicBlockHashable<'a, 'tcx>

impl<'a, 'tcx> Send for FilterInformation<'a, 'tcx>

impl<'a, 'tcx> Send for FindAssignments<'a, 'tcx>

impl<'a, 'tcx> Send for CfgSimplifier<'a, 'tcx>

impl<'a, 'tcx> Send for OptimizationFinder<'a, 'tcx>

impl<'a, 'tcx> Send for SsaVisitor<'a, 'tcx>

impl<'b, 'tcx> !Send for CostChecker<'b, 'tcx>

impl<'b, 'tcx> !Send for CostChecker<'b, 'tcx>

impl<'body, 'tcx> !Send for VnState<'body, 'tcx>

impl<'mir, 'tcx> !Send for ConstPropagator<'mir, 'tcx>

impl<'tcx> !Send for MakeByMoveBody<'tcx>

impl<'tcx> !Send for RenameLocalVisitor<'tcx>

impl<'tcx> !Send for SelfArgVisitor<'tcx>

impl<'tcx> !Send for TransformVisitor<'tcx>

impl<'tcx> !Send for Patch<'tcx>

impl<'tcx> !Send for OptApplier<'tcx>

impl<'tcx> !Send for Merger<'tcx>

impl<'tcx> !Send for StorageRemover<'tcx>

impl<'tcx> !Send for Inliner<'tcx>

impl<'tcx> !Send for RenameToReturnPlace<'tcx>

impl<'tcx> !Send for BasicBlockUpdater<'tcx>

impl<'tcx> !Send for LocalUpdater<'tcx>

impl<'tcx> !Send for Replacer<'tcx>

impl<'tcx> !Send for RevealAllVisitor<'tcx>

impl<'tcx> !Send for AsyncDestructorCtorShimBuilder<'tcx>

impl<'tcx> !Send for CloneShimBuilder<'tcx>

impl<'tcx> !Send for LocalUpdater<'tcx>

impl<'tcx> !Send for LocalReplacer<'tcx>

impl<'tcx> Send for AggregateTy<'tcx>

impl<'tcx> Send for Value<'tcx>

impl<'tcx> Send for Value<'tcx>

impl<'tcx> Send for Value<'tcx>

impl<'tcx> Send for CallKind<'tcx>

impl<'tcx> Send for SuspensionPoint<'tcx>

impl<'tcx> Send for OptimizationData<'tcx>

impl<'tcx> Send for CallSite<'tcx>

impl<'tcx> Send for PromoteTemps<'tcx>

impl<'tcx> Send for RequiredConstsVisitor<'tcx>

impl<'tcx> Send for OptimizationInfo<'tcx>

impl<'tcx> Send for ReplacementMap<'tcx>

impl<'tcx, 'll> !Send for ReplacementVisitor<'tcx, 'll>

impl<P> Send for AssertLint<P>
where P: Send,

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

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

impl<'a, 'tcx> !Send for MirUsedCollector<'a, 'tcx>

impl<'a, 'tcx> !Send for RootCollector<'a, 'tcx>

impl<'a, 'tcx> !Send for PartitioningCx<'a, 'tcx>

impl<'a, 'tcx> !Send for MarkUsedGenericParams<'a, 'tcx>

impl<'tcx> Send for SharedState<'tcx>

impl<'tcx> Send for UsageMap<'tcx>

impl<'tcx> Send for PlacedMonoItems<'tcx>

impl Send for Conflict

impl Send for InCrate

impl Send for HasChanged

impl<'a, D, I> Send for Canonicalizer<'a, D, I>
where D: Sync, <I as Interner>::GenericArg: Send, <I as Interner>::Ty: Send, <I as Interner>::PlaceholderTy: Send, <I as Interner>::PlaceholderRegion: Send, <I as Interner>::PlaceholderConst: Send,

impl<'a, D, I> Send for EagerResolver<'a, D, I>
where D: Sync, <I as Interner>::Ty: Send,

impl<'a, D, I> Send for ReplaceProjectionWith<'a, D, I>
where <I as Interner>::ParamEnv: Send + Sync, <I as Interner>::CanonicalVars: Sync, <I as Interner>::PredefinedOpaques: Sync, D: Sync, <I as Interner>::GenericArgs: Sync + Send, <I as Interner>::DefId: Send + Sync, <I as Interner>::Predicate: Send + Sync, <I as Interner>::BoundVarKinds: Send, <I as Interner>::Term: Send + Sync, <I as Interner>::DefiningOpaqueTypes: Sync, <I as Interner>::GenericArg: Sync, <I as Interner>::ExternalConstraints: Sync,

impl<'a, D, I> Send for EvalCtxt<'a, D, I>
where <I as Interner>::CanonicalVars: Send, <I as Interner>::PredefinedOpaques: Send, D: Sync + Send, <I as Interner>::GenericArgs: Send, <I as Interner>::ParamEnv: Send, <I as Interner>::DefiningOpaqueTypes: Send, <I as Interner>::Term: Send, <I as Interner>::Predicate: Send, <I as Interner>::DefId: Send, <I as Interner>::ExternalConstraints: Send, <I as Interner>::GenericArg: Send,

impl<'a, Infcx, I, F> Send for OrphanChecker<'a, Infcx, I, F>
where F: Send, Infcx: Sync, <I as Interner>::Ty: Send,

impl<'me, 'a, D, I> Send for ReplaceAliasWithInfer<'me, 'a, D, I>
where <I as Interner>::ParamEnv: Send, <I as Interner>::CanonicalVars: Send, <I as Interner>::PredefinedOpaques: Send, D: Sync + Send, <I as Interner>::GenericArgs: Send, <I as Interner>::Ty: Send, <I as Interner>::DefiningOpaqueTypes: Send, <I as Interner>::Term: Send, <I as Interner>::Predicate: Send, <I as Interner>::DefId: Send, <I as Interner>::ExternalConstraints: Send, <I as Interner>::GenericArg: Send,

impl<'me, 'a, D, I, F> Send for TraitProbeCtxt<'me, 'a, D, I, F>
where F: Send, <I as Interner>::DefId: Send, <I as Interner>::CanonicalVars: Send, <I as Interner>::PredefinedOpaques: Send, D: Sync + Send, <I as Interner>::GenericArgs: Send, <I as Interner>::ExternalConstraints: Send, <I as Interner>::ParamEnv: Send, <I as Interner>::DefiningOpaqueTypes: Send, <I as Interner>::Term: Send, <I as Interner>::Predicate: Send, <I as Interner>::GenericArg: Send,

impl<'me, 'a, D, I, F, T> Send for ProbeCtxt<'me, 'a, D, I, F, T>
where F: Send, T: Send, <I as Interner>::CanonicalVars: Send, <I as Interner>::PredefinedOpaques: Send, D: Sync + Send, <I as Interner>::GenericArgs: Send, <I as Interner>::ParamEnv: Send, <I as Interner>::DefiningOpaqueTypes: Send, <I as Interner>::Term: Send, <I as Interner>::Predicate: Send, <I as Interner>::DefId: Send, <I as Interner>::ExternalConstraints: Send, <I as Interner>::GenericArg: Send,

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

impl<D, I> Send for ProofTreeBuilder<D, I>
where D: Send, <I as Interner>::ParamEnv: Send, <I as Interner>::Predicate: Send, <I as Interner>::CanonicalVars: Send, <I as Interner>::DefiningOpaqueTypes: Send, <I as Interner>::GenericArg: Send, <I as Interner>::PredefinedOpaques: Send, <I as Interner>::ExternalConstraints: Send, <I as Interner>::DefId: Send, <I as Interner>::GenericArgs: Send,

impl<I> Send for DebugSolver<I>
where <I as Interner>::ParamEnv: Send, <I as Interner>::Predicate: Send, <I as Interner>::CanonicalVars: Send, <I as Interner>::DefiningOpaqueTypes: Send, <I as Interner>::GenericArg: Send, <I as Interner>::PredefinedOpaques: Send, <I as Interner>::ExternalConstraints: Send, <I as Interner>::DefId: Send, <I as Interner>::GenericArgs: Send,

impl<I> Send for WipProbeStep<I>
where <I as Interner>::CanonicalVars: Send, <I as Interner>::GenericArgs: Send, <I as Interner>::ParamEnv: Send, <I as Interner>::Predicate: Send, <I as Interner>::DefId: Send, <I as Interner>::ExternalConstraints: Send,

impl<I> Send for NotUniqueParam<I>
where <I as Interner>::GenericArg: Send,

impl<I> Send for Candidate<I>
where <I as Interner>::DefId: Send, <I as Interner>::CanonicalVars: Send, <I as Interner>::ExternalConstraints: Send, <I as Interner>::GenericArgs: Send,

impl<I> Send for AsyncCallableRelevantTypes<I>
where <I as Interner>::Ty: Send,

impl<I> Send for NestedGoals<I>
where <I as Interner>::ParamEnv: Send, <I as Interner>::Term: Send, <I as Interner>::Predicate: Send, <I as Interner>::GenericArgs: Send, <I as Interner>::DefId: Send,

impl<I> Send for WipCanonicalGoalEvaluation<I>
where <I as Interner>::CanonicalVars: Send, <I as Interner>::DefiningOpaqueTypes: Send, <I as Interner>::PredefinedOpaques: Send, <I as Interner>::ParamEnv: Send, <I as Interner>::Predicate: Send, <I as Interner>::ExternalConstraints: Send, <I as Interner>::GenericArg: Send, <I as Interner>::GenericArgs: Send, <I as Interner>::DefId: Send,

impl<I> Send for WipCanonicalGoalEvaluationStep<I>
where <I as Interner>::GenericArg: Send, <I as Interner>::CanonicalVars: Send, <I as Interner>::DefId: Send, <I as Interner>::GenericArgs: Send, <I as Interner>::ExternalConstraints: Send, <I as Interner>::ParamEnv: Send, <I as Interner>::Predicate: Send,

impl<I> Send for WipGoalEvaluation<I>
where <I as Interner>::ParamEnv: Send, <I as Interner>::Predicate: Send, <I as Interner>::GenericArg: Send, <I as Interner>::CanonicalVars: Send, <I as Interner>::DefiningOpaqueTypes: Send, <I as Interner>::PredefinedOpaques: Send, <I as Interner>::ExternalConstraints: Send, <I as Interner>::GenericArgs: Send, <I as Interner>::DefId: Send,

impl<I> Send for WipProbe<I>
where <I as Interner>::CanonicalVars: Send, <I as Interner>::DefId: Send, <I as Interner>::GenericArgs: Send, <I as Interner>::ExternalConstraints: Send, <I as Interner>::ParamEnv: Send, <I as Interner>::Predicate: Send,

impl<I, E> Send for OrphanCheckEarlyExit<I, E>
where E: Send, <I as Interner>::Ty: Send,

impl<I, T> Send for OrphanCheckErr<I, T>
where T: Send, <I as Interner>::Ty: Send,

impl<I, T> Send for UncoveredTyParams<I, T>
where T: Send, <I as Interner>::Ty: Send,

impl !Send for FlatToken

impl !Send for TokenType

impl !Send for ExpectedSemi

impl !Send for AttrWrapper

impl !Send for CollectPos

impl !Send for CaptureState

impl !Send for SeqSep

impl !Send for TokenCursor

impl Send for IncOrDec

impl Send for UnaryFixity

impl Send for BlockMode

impl Send for Capturing

impl Send for Recovery

impl Send for Trailing

impl Send for EatOrResult

impl Send for Expected

impl Send for PathStyle

impl Send for AllowPlus

impl Send for AddBoxNew

impl Send for AddParen

impl Send for AsyncImpl

impl Send for BadItemKind

impl Send for BadTypePlus

impl Send for BoxNotPat

impl Send for ColonAsSemi

impl Send for DotDotDot

impl Send for DynAfterMut

impl Send for EqFieldInit

impl Send for InInTypo

impl Send for RemoveLet

impl Send for WrapType

impl Send for MultiSugg

impl Send for FnParseMode

impl Send for NodeRange

impl Send for ParserRange

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

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

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

impl<'a> Send for IncorrectSemicolon<'a>

impl<'a> Send for KwBadCase<'a>

impl<'a> Send for MacroExpandsToAdtField<'a>

impl<'a> Send for MacroRulesVisibility<'a>

impl<'a> Send for NestedAdt<'a>

impl<'a> Send for TransposeDynOrImpl<'a>

impl<'a> Send for TransposeDynOrImplSugg<'a>

impl<'a> Send for UnexpectedTokenAfterDot<'a>

impl<'a> Send for UnknownPrefix<'a>

impl<'psess, 'src> !Send for StringReader<'psess, 'src>

impl<'psess, 'src> !Send for TokenTreesReader<'psess, 'src>

impl Send for Alignment

impl Send for DebugHex

impl Send for ParseMode

impl Send for Sign

impl Send for Suggestion

impl Send for InnerOffset

impl Send for InnerSpan

impl Send for ParseError

impl<'a> Send for Count<'a>

impl<'a> Send for Piece<'a>

impl<'a> Send for Position<'a>

impl<'a> Send for Argument<'a>

impl<'a> Send for FormatSpec<'a>

impl<'a> Send for Parser<'a>

impl Send for ReportOn

impl Send for MacroExport

impl Send for UnusedNote

impl Send for Id

impl Send for Duplicate

impl Send for VarKind

impl Send for Context

impl Send for ItemKind

impl Send for DeadItem

impl Send for AbiNe

impl Send for AbiOf

impl Send for Cold

impl Send for Confusables

impl Send for Deprecated

impl Send for DocInvalid

impl Send for ExportName

impl Send for ExternMain

impl Send for LayoutAbi

impl Send for LayoutAlign

impl Send for LayoutOf

impl Send for LayoutSize

impl Send for Link

impl Send for LinkOrdinal

impl Send for LinkSection

impl Send for Linkage

impl Send for MacroUse

impl Send for NoLink

impl Send for NoMainErr

impl Send for NoMangle

impl Send for NoPatterns

impl Send for PassByValue

impl Send for ReprIdent

impl Send for Unused

impl Send for UsedStatic

impl Send for Node

impl Send for NodeStats

impl Send for RWU

impl Send for RWUTable

impl Send for CaptureInfo

impl Send for LiveNode

impl Send for LocalInfo

impl Send for Variable

impl Send for BlockInfo

impl<'a> Send for BreakInsideClosure<'a>

impl<'a> Send for BreakInsideCoroutine<'a>

impl<'a> Send for BreakNonLoop<'a>

impl<'a> Send for DocAliasBadChar<'a>

impl<'a> Send for DocAliasBadLocation<'a>

impl<'a> Send for DocAliasEmpty<'a>

impl<'a> Send for DocAliasNotAnAlias<'a>

impl<'a> Send for DocAliasStartEnd<'a>

impl<'a> Send for DocAttrNotCrateLevel<'a>

impl<'a> Send for DocExpectStr<'a>

impl<'a> Send for IgnoredAttr<'a>

impl<'a> Send for IgnoredAttrWithMacro<'a>

impl<'a> Send for IncorrectTarget<'a>

impl<'a> Send for LinkName<'a>

impl<'a> Send for MissingConstStabAttr<'a>

impl<'a> Send for MissingStabilityAttr<'a>

impl<'a> Send for OutsideLoop<'a>

impl<'a> Send for UnlabeledInLabeledBlock<'a>

impl<'a> Send for UselessAssignment<'a>

impl<'a, 'hir> !Send for HirIdValidator<'a, 'hir>

impl<'a, 'tcx> !Send for Liveness<'a, 'tcx>

impl<'a, 'tcx> !Send for Annotator<'a, 'tcx>

impl<'a, 'tcx> !Send for CaptureCollector<'a, 'tcx>

impl<'a, 'tcx> !Send for WeakLangItemVisitor<'a, 'tcx>

impl<'ast, 'tcx> !Send for LanguageItemCollector<'ast, 'tcx>

impl<'desc, 'tcx> Send for UnreachableDueToUninhabited<'desc, 'tcx>

impl<'k> !Send for StatCollector<'k>

impl<'tcx> !Send for ItemLike<'tcx>

impl<'tcx> !Send for CheckAttrVisitor<'tcx>

impl<'tcx> !Send for CheckConstVisitor<'tcx>

impl<'tcx> !Send for DeadVisitor<'tcx>

impl<'tcx> !Send for MarkSymbolVisitor<'tcx>

impl<'tcx> !Send for EntryContext<'tcx>

impl<'tcx> !Send for UnwrapLayoutCx<'tcx>

impl<'tcx> !Send for LibFeatureCollector<'tcx>

impl<'tcx> !Send for IrMaps<'tcx>

impl<'tcx> !Send for CheckLoopVisitor<'tcx>

impl<'tcx> !Send for CheckNakedAsmInNakedFn<'tcx>

impl<'tcx> !Send for CheckParameters<'tcx>

impl<'tcx> !Send for ReachableContext<'tcx>

impl<'tcx> !Send for CheckTraitImplStable<'tcx>

impl<'tcx> !Send for Checker<'tcx>

impl<'tcx> !Send for MissingStabilityAnnotations<'tcx>

impl<'tcx> Send for MultipleDeadCodes<'tcx>

impl<'tcx> Send for ParentInfo<'tcx>

impl<'tcx> Send for CollectLitsVisitor<'tcx>

impl Send for Presence

impl Send for RangeEnd

impl Send for SliceKind

impl Send for IntRange

impl Send for OpaqueId

impl Send for Slice

impl Send for GappedRange

impl Send for Overlap

impl Send for Uncovered

impl Send for PatId

impl Send for FieldPat

impl<'a, 'p, Cx> Send 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> Send for PlaceCtxt<'a, Cx>
where Cx: Sync, <Cx as PatCx>::Ty: Sync,

impl<'p, 'tcx> !Send for RustcPatCtxt<'p, 'tcx>

impl<'p, Cx> Send 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> Send 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> Send 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> Send for MatchArm<'p, Cx>
where <Cx as PatCx>::ArmData: Send, <Cx as PatCx>::Ty: Sync, <Cx as PatCx>::PatData: Sync, <Cx as PatCx>::VariantIdx: Sync, <Cx as PatCx>::StrLit: Sync,

impl<'p, Cx> Send 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> Send for Matrix<'p, Cx>
where <Cx as PatCx>::Ty: Send + Sync, <Cx as PatCx>::PatData: Sync, <Cx as PatCx>::VariantIdx: Sync, <Cx as PatCx>::StrLit: Sync,

impl<'p, Cx> Send 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> Send 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> Send 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> Send for UsefulnessReport<'p, Cx>
where <Cx as PatCx>::Ty: Send + Sync, <Cx as PatCx>::ArmData: Send, <Cx as PatCx>::VariantIdx: Send + Sync, <Cx as PatCx>::StrLit: Send + Sync, <Cx as PatCx>::PatData: Sync,

impl<'tcx> Send for EnumInfo<'tcx>

impl<'tcx> Send for NonExhaustiveOmittedPattern<'tcx>

impl<'tcx> Send for RevealedTy<'tcx>

impl<Cx> Send for Constructor<Cx>
where <Cx as PatCx>::VariantIdx: Send, <Cx as PatCx>::StrLit: Send,

impl<Cx> Send for ConstructorSet<Cx>

impl<Cx> Send for SplitConstructorSet<Cx>
where <Cx as PatCx>::VariantIdx: Send, <Cx as PatCx>::StrLit: Send,

impl<Cx> Send for DeconstructedPat<Cx>
where <Cx as PatCx>::Ty: Send, <Cx as PatCx>::PatData: Send, <Cx as PatCx>::VariantIdx: Send, <Cx as PatCx>::StrLit: Send,

impl<Cx> Send for IndexedPat<Cx>
where <Cx as PatCx>::Ty: Send, <Cx as PatCx>::PatData: Send, <Cx as PatCx>::VariantIdx: Send, <Cx as PatCx>::StrLit: Send,

impl<Cx> Send for WitnessPat<Cx>
where <Cx as PatCx>::Ty: Send, <Cx as PatCx>::VariantIdx: Send, <Cx as PatCx>::StrLit: Send,

impl<Cx> Send for PlaceInfo<Cx>
where <Cx as PatCx>::Ty: Send,

impl<Cx> Send for WitnessMatrix<Cx>
where <Cx as PatCx>::Ty: Send, <Cx as PatCx>::VariantIdx: Send, <Cx as PatCx>::StrLit: Send,

impl<Cx> Send for WitnessStack<Cx>
where <Cx as PatCx>::Ty: Send, <Cx as PatCx>::VariantIdx: Send, <Cx as PatCx>::StrLit: Send,

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

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

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

impl<'a, 'tcx> !Send for PrivateItemsInPublicInterfacesChecker<'a, 'tcx>

impl<'a, 'tcx> !Send for ReachEverythingInTheInterfaceVisitor<'a, 'tcx>

impl<'a, 'tcx> !Send for TestReachabilityVisitor<'a, 'tcx>

impl<'a, 'tcx, VL, const SHALLOW: bool> !Send for FindMin<'a, 'tcx, VL, SHALLOW>

impl<'tcx> !Send for EmbargoVisitor<'tcx>

impl<'tcx> !Send for LazyDefPathStr<'tcx>

impl<'tcx> !Send for NamePrivacyVisitor<'tcx>

impl<'tcx> !Send for TypePrivacyVisitor<'tcx>

impl<'v, 'tcx, V> !Send for DefIdVisitorSkeleton<'v, 'tcx, V>

impl<'a, 'tcx> !Send for QueryKeyStringBuilder<'a, 'tcx>

impl<'tcx> !Send for QueryCtxt<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx> Send for QueryType<'tcx>

impl<'tcx, C, const ANON: bool, const DEPTH_LIMIT: bool, const FEEDABLE: bool> !Send for DynamicConfig<'tcx, C, ANON, DEPTH_LIMIT, FEEDABLE>

impl Send for Alias

impl Send for StackCount

impl Send for QueryMode

impl Send for QueryResult

impl Send for EdgeFilter

impl Send for DepKind

impl Send for DepNode

impl Send for EdgesVec

impl Send for EdgeIndex

impl Send for TaskDeps

impl Send for WorkProduct

impl Send for EdgeHeader

impl Send for NodeInfo

impl Send for Stat

impl Send for Unpacked

impl Send for Cycle

impl Send for CycleStack

impl Send for CycleUsage

impl Send for Reentrant

impl Send for QueryInfo

impl Send for QueryJob

impl Send for QueryJobId

impl Send for QueryLatch

impl Send for QueryWaiter

impl Send for CycleError

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

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

impl<'a> Send for MarkFrame<'a>

impl<'tcx, K> !Send for JobOwner<'tcx, K>

impl<D> !Send for DepGraph<D>

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

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

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

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

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

impl<K> Send for QueryState<K>
where K: Send,

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

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

impl<Key, Value> Send for Cache<Key, Value>
where Key: Send, Value: Send,

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

impl<Tcx> Send for DepKindStruct<Tcx>

impl<V> Send for DefIdCache<V>
where V: Send,

impl<V> Send for SingleCache<V>
where V: Send,

impl !Send for UnusedImport

impl !Send for DeriveData

impl !Send for MacroData

impl Send for DiagMode

impl Send for FoundUse

impl Send for Instead

impl Send for Determinacy

impl Send for ModuleKind

impl Send for Used

impl Send for Weak

impl Send for DefinedHere

impl Send for ImportIdent

impl Send for UsePrelude

impl Send for PatBoundCtx

impl Send for ModuleOnly

impl Send for BaseError

impl Send for BindingInfo

impl Send for LifetimeRib

impl Send for DocFragment

impl Send for BindingKey

impl Send for Finalize

impl Send for Segment

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

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

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

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

impl<'a> Send for AddAsNonDerive<'a>

impl<'a> Send for IdentInScopeButItIsDesc<'a>

impl<'a> Send for ImportsCannotReferTo<'a>

impl<'a> Send for IsPrivate<'a>

impl<'a> Send for MacroExpectedFound<'a>

impl<'a, 'ast, 'ra, 'tcx> !Send for LateResolutionVisitor<'a, 'ast, 'ra, 'tcx>

impl<'a, 'ra, 'tcx> !Send for BuildReducedGraphVisitor<'a, 'ra, 'tcx>

impl<'a, 'ra, 'tcx> !Send for UnusedImportCheckVisitor<'a, 'ra, 'tcx>

impl<'a, 'ra, 'tcx> !Send for DefCollector<'a, 'ra, 'tcx>

impl<'a, 'ra, 'tcx> !Send for EffectiveVisibilitiesVisitor<'a, 'ra, 'tcx>

impl<'a, 'ra, 'tcx> !Send for ItemInfoCollector<'a, 'ra, 'tcx>

impl<'ast> !Send for LifetimeFinder<'ast>

impl<'ast> !Send for DiagMetadata<'ast>

impl<'ra> !Send for ParentId<'ra>

impl<'ra> !Send for LexicalScopeBinding<'ra>

impl<'ra> !Send for ModuleOrUniformRoot<'ra>

impl<'ra> !Send for NameBindingKind<'ra>

impl<'ra> !Send for PathResult<'ra>

impl<'ra> !Send for ResolutionError<'ra>

impl<'ra> !Send for Scope<'ra>

impl<'ra> !Send for ScopeSet<'ra>

impl<'ra> !Send for ImportKind<'ra>

impl<'ra> !Send for RibKind<'ra>

impl<'ra> !Send for MacroRulesScope<'ra>

impl<'ra> !Send for ImportData<'ra>

impl<'ra> !Send for NameResolution<'ra>

impl<'ra> !Send for UnnecessaryQualification<'ra>

impl<'ra> !Send for MacroRulesBinding<'ra>

impl<'ra> !Send for AmbiguityError<'ra>

impl<'ra> !Send for ExternPreludeEntry<'ra>

impl<'ra> !Send for Module<'ra>

impl<'ra> !Send for ModuleData<'ra>

impl<'ra> !Send for NameBindingData<'ra>

impl<'ra> !Send for ParentScope<'ra>

impl<'ra> !Send for PrivacyError<'ra>

impl<'ra> !Send for ResolverArenas<'ra>

impl<'ra, 'tcx> !Send for Resolver<'ra, 'tcx>

impl<'ra, R = Res<NodeId>> !Send for Rib<'ra, R>

impl Send for TyQ

impl<'tcx> !Send for TransformTy<'tcx>

impl<'tcx> Send for DictKey<'tcx>

impl Send for FileEncoder

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

impl !Send for NativeLib

impl !Send for Untracked

impl !Send for ParseSess

impl !Send for Session

impl Send for FieldKind

impl Send for SizeKind

impl Send for CFGuard

impl Send for CrateType

impl Send for DebugInfo

impl Send for EntryFnType

impl Send for FmtDebug

impl Send for Input

impl Send for Lto

impl Send for LtoCli

impl Send for OomStrategy

impl Send for OptLevel

impl Send for OutFileName

impl Send for OutputType

impl Send for PAuthKey

impl Send for Passes

impl Send for Polonius

impl Send for PpHirMode

impl Send for PpMode

impl Send for PrintKind

impl Send for Strip

impl Send for PathKind

impl Send for CodeStats

impl Send for FieldInfo

impl Send for VariantInfo

impl Send for CheckCfg

impl Send for ExternEntry

impl Send for Externs

impl Send for JsonConfig

impl Send for Options

impl Send for OutputTypes

impl Send for PacRet

impl Send for CrateSource

impl Send for DllImport

impl Send for ExternCrate

impl Send for GatedSpans

impl Send for SearchPath

impl Send for CompilerIO

impl Send for Limit

impl Send for Limits

impl Send for NativeLib

impl<'a> Send for CrateNameInvalid<'a>

impl<'a> Send for FileIsNotWriteable<'a>

impl<'a> Send for FileWriteFail<'a>

impl<'a> Send for InvalidLiteralSuffix<'a>

impl<'a> Send for FileSearch<'a>

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

impl<'tcx> !Send for BodyBuilder<'tcx>

impl<'tcx> !Send for TablesWrapper<'tcx>

impl<'tcx> !Send for Tables<'tcx>

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

impl !Send for CacheEntry

impl !Send for SourceMap

impl !Send for FileLines

impl !Send for Loc

impl Send for Edition

impl Send for FileName

impl Send for AstPass

impl Send for ExpnKind

impl Send for MacroKind

impl Send for CrateNum

impl Send for DefId

impl Send for DefIndex

impl Send for DefPathHash

impl Send for LocalDefId

impl Send for ModDefId

impl Send for ExpnData

impl Send for ExpnHash

impl Send for ExpnId

impl Send for ExpnIndex

impl Send for HygieneData

impl Send for LocalExpnId

impl Send for InlineCtxt

impl Send for Interned

impl Send for Span

impl Send for AttrId

impl Send for BytePos

impl Send for CharPos

impl Send for InnerSpan

impl Send for LineInfo

impl Send for SourceFile

impl Send for SpanData

impl Send for AllKeywords

impl Send for Ident

impl Send for Interner

impl Send for Symbol

impl Send for SymbolIndex

impl<'a> Send for FileNameDisplay<'a>

impl<'sm> !Send for CachingSourceMapView<'sm>

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

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

impl Send for Kind

impl Send for TestOutput

impl Send for SymbolPath

impl Send for BinderLevel

impl<'tcx> !Send for SymbolPrinter<'tcx>

impl<'tcx> !Send for SymbolNamesTest<'tcx>

impl<'tcx> !Send for SymbolMangler<'tcx>

impl Send for AbiKind

impl Send for Conv

impl Send for PassMode

impl Send for FloatConv

impl Send for RegPassKind

impl Send for ABI

impl Send for FloatConv

impl Send for RegPassKind

impl Send for Flavor

impl Send for Class

impl Send for Abi

impl Send for AbiDisabled

impl Send for Arch

impl Send for TargetAbi

impl Send for Cc

impl Send for CodeModel

impl Send for Lld

impl Send for LldFlavor

impl Send for RelocModel

impl Send for RelroLevel

impl Send for TlsModel

impl Send for WasmCAbi

impl Send for Stability

impl Send for Sdata

impl Send for CastTarget

impl Send for Uniform

impl Send for X86Options

impl Send for Memory

impl Send for AbiData

impl Send for Target

impl Send for X86Abi

impl<'a, Ty> Send for ArgAbi<'a, Ty>
where Ty: Send,

impl<'a, Ty> Send for FnAbi<'a, Ty>
where Ty: Send,

impl Send for FailureCode

impl Send for TyCategory

impl Send for ArgKind

impl Send for DefIdOrName

impl Send for PrefixKind

impl Send for SuffixKind

impl Send for DropVictim

impl Send for Elaborate

impl Send for SubId

impl Send for FnUniqTypes

impl Send for Select

impl Send for InProgress

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

impl<'a> Send for RegionOriginNote<'a>

impl<'a> Send for SourceKindSubdiag<'a>

impl<'a> Send for SuggestAccessingField<'a>

impl<'a> Send for HirTraitObjectVisitor<'a>

impl<'a> Send for ReplaceImplTraitVisitor<'a>

impl<'a> Send for DescriptionCtx<'a>

impl<'a> Send for RegionExplanation<'a>

impl<'a> Send for AmbiguousImpl<'a>

impl<'a> Send for AmbiguousReturn<'a>

impl<'a> Send for AnnotationRequired<'a>

impl<'a> Send for DumpVTableEntries<'a>

impl<'a> Send for FulfillReqLifetime<'a>

impl<'a> Send for InferenceBadError<'a>

impl<'a> Send for LfBoundNotSatisfied<'a>

impl<'a> Send for OutlivesBound<'a>

impl<'a> Send for OutlivesContent<'a>

impl<'a> Send for RefLongerThanData<'a>

impl<'a, 'b, 'tcx> !Send for AssocTypeNormalizer<'a, 'b, 'tcx>

impl<'a, 'tcx> !Send for FindInferSourceVisitor<'a, 'tcx>

impl<'a, 'tcx> !Send for SameTypeModuloInfer<'a, 'tcx>

impl<'a, 'tcx> !Send for TypeErrCtxt<'a, 'tcx>

impl<'a, 'tcx> !Send for InspectCandidate<'a, 'tcx>

impl<'a, 'tcx> !Send for InspectGoal<'a, 'tcx>

impl<'a, 'tcx> !Send for DeeplyNormalizeForDiagnosticsFolder<'a, 'tcx>

impl<'a, 'tcx> !Send for FulfillProcessor<'a, 'tcx>

impl<'a, 'tcx> !Send for QueryNormalizer<'a, 'tcx>

impl<'a, 'tcx> !Send for BoundVarReplacer<'a, 'tcx>

impl<'a, 'tcx> !Send for PlaceholderReplacer<'a, 'tcx>

impl<'a, 'tcx> !Send for WfPredicates<'a, 'tcx>

impl<'a, 'tcx> Send for CoroutineData<'a, 'tcx>

impl<'a, 'tcx> Send for AmbiguityCausesVisitor<'a, 'tcx>

impl<'a, 'tcx, E = ScrubbedTraitError<'tcx>> !Send for ObligationCtxt<'a, 'tcx, E>

impl<'cx> Send for AutoTraitInfo<'cx>

impl<'cx, 'tcx> !Send for NiceRegionError<'cx, 'tcx>

impl<'cx, 'tcx> !Send for SelectionContext<'cx, 'tcx>

impl<'hir> !Send for FindExprBySpan<'hir>

impl<'me, 'tcx, E> !Send for NormalizationFolder<'me, 'tcx, E>

impl<'o, 'tcx> !Send for TraitObligationStackList<'o, 'tcx>

impl<'prev, 'tcx> !Send for TraitObligationStack<'prev, 'tcx>

impl<'tcx> !Send for ActualImplExplNotes<'tcx>

impl<'tcx> !Send for TyOrSig<'tcx>

impl<'tcx> !Send for ClosureEraser<'tcx>

impl<'tcx> !Send for FindNestedTypeVisitor<'tcx>

impl<'tcx> !Send for TyPathVisitor<'tcx>

impl<'tcx> !Send for TypeParamSpanVisitor<'tcx>

impl<'tcx> !Send for ReplaceImplTraitFolder<'tcx>

impl<'tcx> !Send for TraitPlaceholderMismatch<'tcx>

impl<'tcx> !Send for SolverDelegate<'tcx>

impl<'tcx> !Send for AutoTraitFinder<'tcx>

impl<'tcx> !Send for EraseEscapingBoundRegions<'tcx>

impl<'tcx> !Send for IllegalSelfTypeVisitor<'tcx>

impl<'tcx> !Send for MatchAgainstFreshVars<'tcx>

impl<'tcx> !Send for TraitAliasExpander<'tcx>

impl<'tcx> Send for InferSourceKind<'tcx>

impl<'tcx> Send for OverflowCause<'tcx>

impl<'tcx> Send for ChildMode<'tcx>

impl<'tcx> Send for NextSolverError<'tcx>

impl<'tcx> Send for RegionTarget<'tcx>

impl<'tcx> Send for FulfillmentErrorCode<'tcx>

impl<'tcx> Send for CopyImplementationError<'tcx>

impl<'tcx> Send for InfringingFieldsReason<'tcx>

impl<'tcx> Send for ProjectAndUnifyResult<'tcx>

impl<'tcx> Send for Projected<'tcx>

impl<'tcx> Send for ProjectionCandidate<'tcx>

impl<'tcx> Send for ProjectionCandidateSet<'tcx>

impl<'tcx> Send for ProjectionError<'tcx>

impl<'tcx> Send for BuiltinImplConditions<'tcx>

impl<'tcx> Send for IntercrateAmbiguityCause<'tcx>

impl<'tcx> Send for Inserted<'tcx>

impl<'tcx> Send for VtblSegment<'tcx>

impl<'tcx> Send for InferSource<'tcx>

impl<'tcx> Send for InsertableGenericArgs<'tcx>

impl<'tcx> Send for AnonymousParamInfo<'tcx>

impl<'tcx> Send for ObligationCauseAsDiagArg<'tcx>

impl<'tcx> Send for ImplCandidate<'tcx>

impl<'tcx> Send for NegativePositiveConflict<'tcx>

impl<'tcx> Send for OpaqueCapturesLifetime<'tcx>

impl<'tcx> Send for BestObligation<'tcx>

impl<'tcx> Send for ObligationStorage<'tcx>

impl<'tcx> Send for NormalizesToTermHack<'tcx>

impl<'tcx> Send for RegionDeps<'tcx>

impl<'tcx> Send for OverlapResult<'tcx>

impl<'tcx> Send for OldSolverError<'tcx>

impl<'tcx> Send for PendingPredicateObligation<'tcx>

impl<'tcx> Send for Progress<'tcx>

impl<'tcx> Send for EvaluatedCandidate<'tcx>

impl<'tcx> Send for ProvisionalEvaluationCache<'tcx>

impl<'tcx> Send for SelectionCandidateSet<'tcx>

impl<'tcx> Send for FutureCompatOverlapError<'tcx>

impl<'tcx> Send for OverlapError<'tcx>

impl<'tcx> Send for FulfillmentError<'tcx>

impl<'tcx> Send for TraitAliasExpansionInfo<'tcx>

impl<'tcx, E> Send for FulfillmentCtxt<'tcx, E>
where E: Send,

impl<'tcx, E> Send for FulfillmentContext<'tcx, E>
where E: Send,

impl<'tcx, Op> Send for TypeOpOutput<'tcx, Op>
where <Op as TypeOp<'tcx>>::Output: Send, <Op as TypeOp<'tcx>>::ErrorInfo: Send,

impl<'tcx, T> !Send for Highlighted<'tcx, T>

impl<'v> Send for ReturnsVisitor<'v>

impl<'v> Send for SelfVisitor<'v>

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

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

impl<I, J> Send for PotentialSiblings<I, J>
where I: Send, J: Send,

impl Send for Byte

impl Send for Err

impl Send for Quantifier

impl Send for State

impl Send for State

impl Send for Uninhabited

impl Send for Assume

impl<'cx, 'tcx> !Send for TransmuteTypeEnv<'cx, 'tcx>

impl<'tcx> Send for Def<'tcx>

impl<'tcx> Send for Ref<'tcx>

impl<'tcx> Send for Types<'tcx>

impl<D, R> Send for Tree<D, R>
where D: Send, R: Send,

impl<L, C> Send for MaybeTransmutableQuery<L, C>
where L: Send, C: Send,

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

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

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

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

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

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

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

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

impl Send for DtorType

impl<'a, 'tcx> !Send for ImplTraitInTraitFinder<'a, 'tcx>

impl<'a, 'tcx> Send for IsThirPolymorphic<'a, 'tcx>

impl<'tcx> !Send for OpaqueTypeCollector<'tcx>

impl<'tcx> Send for DuplicateArg<'tcx>

impl<'tcx> Send for MultipleArrayFieldsSimdType<'tcx>

impl<'tcx> Send for NeedsDropOverflow<'tcx>

impl<'tcx> Send for NonPrimitiveSimdType<'tcx>

impl<'tcx> Send for NotParam<'tcx>

impl<'tcx> Send for OversizedSimdType<'tcx>

impl<'tcx> Send for ZeroLengthSimdType<'tcx>

impl<'tcx, F> !Send for NeedsDropTypes<'tcx, F>

impl Send for InferConst

impl Send for Filter

impl Send for ClosureKind

impl Send for Variance

impl Send for TreatParams

impl Send for PathKind

impl Send for UsageKind

impl Send for Certainty

impl Send for GoalSource

impl Send for MaybeCause

impl Send for Reveal

impl Send for AliasTyKind

impl Send for DynKind

impl Send for FloatTy

impl Send for InferTy

impl Send for IntTy

impl Send for IntVarValue

impl Send for UintTy

impl Send for ConstVid

impl Send for TypeFlags

impl Send for RegionVid

impl Send for CycleHeads

impl Send for StackDepth

impl Send for NoSolution

impl Send for BoundVar

impl Send for FloatVid

impl Send for IntVid

impl Send for TyVid

impl Send for FoundFlags

impl<'a, I> Send for ArgFolder<'a, I>
where I: Send, <I as Interner>::GenericArg: Sync,

impl<'a, I> Send for OutlivesCollector<'a, I>
where I: Send, <I as Interner>::Region: Send, <I as Interner>::ParamTy: Send, <I as Interner>::PlaceholderTy: Send, <I as Interner>::GenericArgs: Send, <I as Interner>::DefId: Send, <I as Interner>::Ty: Send,

impl<'a, I, Iter> Send for IterInstantiatedCopied<'a, I, Iter>
where <Iter as IntoIterator>::IntoIter: Send, I: Send, <I as Interner>::GenericArg: Sync,

impl<'a, X> Send for CacheData<'a, X>
where <X as Cx>::Result: Send, <X as Cx>::Input: Sync,

impl<'infcx, Infcx, I> Send for SolverRelating<'infcx, Infcx, I>
where <I as Interner>::ParamEnv: Send, Infcx: Sync, <I as Interner>::Predicate: Send, <I as Interner>::Ty: Send,

impl<D, X> Send for SearchGraph<D, X>
where D: Send, <X as Cx>::Input: Send, <X as Cx>::Result: Send,

impl<DefId> Send for SimplifiedType<DefId>
where DefId: Send,

impl<I> Send for TypeError<I>
where <I as Interner>::Region: Send, <I as Interner>::BoundRegion: Send, <I as Interner>::Ty: Send, <I as Interner>::Const: Send, <I as Interner>::DefId: Send, <I as Interner>::Safety: Send, <I as Interner>::Abi: Send, <I as Interner>::BoundExistentialPredicates: Send,

impl<I> Send for GenericArgKind<I>
where <I as Interner>::Region: Send, <I as Interner>::Ty: Send, <I as Interner>::Const: Send,

impl<I> Send for TermKind<I>
where <I as Interner>::Ty: Send, <I as Interner>::Const: Send,

impl<I> Send for TypingMode<I>

impl<I> Send for Component<I>
where <I as Interner>::Region: Send, <I as Interner>::ParamTy: Send, <I as Interner>::PlaceholderTy: Send, <I as Interner>::GenericArgs: Send, <I as Interner>::DefId: Send,

impl<I> Send for ExistentialPredicate<I>
where <I as Interner>::DefId: Send, <I as Interner>::GenericArgs: Send, <I as Interner>::Term: Send,

impl<I> Send for ClauseKind<I>
where <I as Interner>::Const: Send, <I as Interner>::Ty: Send, <I as Interner>::GenericArg: Send, <I as Interner>::Region: Send, <I as Interner>::Term: Send, <I as Interner>::DefId: Send, <I as Interner>::GenericArgs: Send,

impl<I> Send for PredicateKind<I>
where <I as Interner>::DefId: Send, <I as Interner>::Const: Send, <I as Interner>::Term: Send, <I as Interner>::Ty: Send, <I as Interner>::GenericArg: Send, <I as Interner>::Region: Send, <I as Interner>::GenericArgs: Send,

impl<I> Send for VarianceDiagInfo<I>
where <I as Interner>::Ty: Send,

impl<I> Send for CandidateSource<I>
where <I as Interner>::DefId: Send,

impl<I> Send for ProbeKind<I>

impl<I> Send for TyKind<I>

impl<I> Send for ValidateBoundVars<I>
where <I as Interner>::BoundVarKinds: Send, <I as Interner>::Ty: Send,

impl<I> Send for CanonicalVarValues<I>
where <I as Interner>::GenericArgs: Send,

impl<I> Send for UnevaluatedConst<I>
where <I as Interner>::DefId: Send, <I as Interner>::GenericArgs: Send,

impl<I> Send for ClauseWithSupertraitSpan<I>
where <I as Interner>::Predicate: Send, <I as Interner>::Span: Send,

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

impl<I> Send for OpaqueTypeKey<I>
where <I as Interner>::LocalDefId: Send, <I as Interner>::GenericArgs: Send,

impl<I> Send for AliasTerm<I>
where <I as Interner>::GenericArgs: Send, <I as Interner>::DefId: Send,

impl<I> Send for CoercePredicate<I>
where <I as Interner>::Ty: Send,

impl<I> Send for ExistentialProjection<I>
where <I as Interner>::DefId: Send, <I as Interner>::GenericArgs: Send, <I as Interner>::Term: Send,

impl<I> Send for ExistentialTraitRef<I>
where <I as Interner>::DefId: Send, <I as Interner>::GenericArgs: Send,

impl<I> Send for HostEffectPredicate<I>
where <I as Interner>::DefId: Send, <I as Interner>::GenericArgs: Send,

impl<I> Send for NormalizesTo<I>
where <I as Interner>::Term: Send, <I as Interner>::GenericArgs: Send, <I as Interner>::DefId: Send,

impl<I> Send for ProjectionPredicate<I>
where <I as Interner>::Term: Send, <I as Interner>::GenericArgs: Send, <I as Interner>::DefId: Send,

impl<I> Send for SubtypePredicate<I>
where <I as Interner>::Ty: Send,

impl<I> Send for TraitPredicate<I>
where <I as Interner>::DefId: Send, <I as Interner>::GenericArgs: Send,

impl<I> Send for TraitRef<I>
where <I as Interner>::DefId: Send, <I as Interner>::GenericArgs: Send,

impl<I> Send for Probe<I>

impl<I> Send for ExternalConstraintsData<I>
where <I as Interner>::GenericArg: Send, <I as Interner>::Region: Send, <I as Interner>::Ty: Send, <I as Interner>::LocalDefId: Send, <I as Interner>::GenericArgs: Send, <I as Interner>::ParamEnv: Send, <I as Interner>::Predicate: Send,

impl<I> Send for NestedNormalizationGoals<I>
where <I as Interner>::ParamEnv: Send, <I as Interner>::Predicate: Send,

impl<I> Send for PredefinedOpaquesData<I>
where <I as Interner>::Ty: Send, <I as Interner>::LocalDefId: Send, <I as Interner>::GenericArgs: Send,

impl<I> Send for Response<I>

impl<I> Send for ClosureArgs<I>
where <I as Interner>::GenericArgs: Send,

impl<I> Send for ClosureArgsParts<I>
where <I as Interner>::GenericArgsSlice: Send, <I as Interner>::Ty: Send,

impl<I> Send for CoroutineArgs<I>
where <I as Interner>::GenericArgs: Send,

impl<I> Send for CoroutineArgsParts<I>
where <I as Interner>::GenericArgsSlice: Send, <I as Interner>::Ty: Send,

impl<I> Send for CoroutineClosureArgs<I>
where <I as Interner>::GenericArgs: Send,

impl<I> Send for CoroutineClosureSignature<I>
where <I as Interner>::Ty: Send, <I as Interner>::Safety: Send, <I as Interner>::Abi: Send,

impl<I> Send for FoldEscapingRegions<I>
where I: Send, <I as Interner>::Region: Send,

impl<I> Send for GenSig<I>
where <I as Interner>::Ty: Send,

impl<I> Send for AliasTy<I>
where <I as Interner>::GenericArgs: Send, <I as Interner>::DefId: Send,

impl<I> Send for FnHeader<I>
where <I as Interner>::Safety: Send, <I as Interner>::Abi: Send,

impl<I> Send for FnSig<I>
where <I as Interner>::Tys: Send, <I as Interner>::Safety: Send, <I as Interner>::Abi: Send,

impl<I> Send for FnSigTys<I>
where <I as Interner>::Tys: Send,

impl<I> Send for TypeAndMut<I>
where <I as Interner>::Ty: Send,

impl<I, A> Send for OutlivesPredicate<I, A>
where A: Send, <I as Interner>::Region: Send,

impl<I, It> Send for FilterToTraits<I, It>
where It: Send, I: Send,

impl<I, Iter, A> Send for IterInstantiated<I, Iter, A>
where <Iter as IntoIterator>::IntoIter: Send, I: Send, A: Send,

impl<I, O> Send for Elaborator<I, O>
where I: Send, O: Send, <I as Interner>::BoundVarKinds: Send, <I as Interner>::DefId: Send, <I as Interner>::Const: Send, <I as Interner>::Term: Send, <I as Interner>::Ty: Send, <I as Interner>::GenericArg: Send, <I as Interner>::Region: Send, <I as Interner>::GenericArgs: Send,

impl<I, P> Send for Goal<I, P>
where <I as Interner>::ParamEnv: Send, P: Send,

impl<I, P> Send for QueryInput<I, P>
where <I as Interner>::PredefinedOpaques: Send, <I as Interner>::ParamEnv: Send, P: Send,

impl<I, T> Send for Binder<I, T>
where T: Send, <I as Interner>::BoundVarKinds: Send,

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

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

impl<I, T> Send for State<I, T>
where T: Send, <I as Interner>::GenericArgs: Send,

impl<I, V> Send for Canonical<I, V>
where V: Send, <I as Interner>::CanonicalVars: Send,

impl<I, V> Send for CanonicalQueryInput<I, V>

impl<I, const INSTANTIATE_LHS_WITH_INFER: bool, const INSTANTIATE_RHS_WITH_INFER: bool> Send for DeepRejectCtxt<I, INSTANTIATE_LHS_WITH_INFER, INSTANTIATE_RHS_WITH_INFER>
where I: Send,

impl<Iter> Send for IterIdentityCopied<Iter>
where <Iter as IntoIterator>::IntoIter: Send,

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

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

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

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

impl<X> Send for CacheEntry<X>
where <X as Cx>::Tracked<<X as Cx>::Result>: Send, <X as Cx>::Input: Send,

impl<X> Send for GlobalCache<X>
where <X as Cx>::Input: Send, <X as Cx>::Tracked<<X as Cx>::Result>: Send,

impl<X> Send for Success<X>
where <X as Cx>::Tracked<<X as Cx>::Result>: Send, <X as Cx>::Input: Send,

impl<X> Send for WithOverflow<X>
where <X as Cx>::Tracked<<X as Cx>::Result>: Send, <X as Cx>::Input: Send,

impl<X> Send for NestedGoals<X>
where <X as Cx>::Input: Send,

impl<X> Send for ProvisionalCacheEntry<X>
where <X as Cx>::Result: Send, <X as Cx>::Input: Send,

impl<X> Send for StackEntry<X>
where <X as Cx>::Input: Send, <X as Cx>::Result: Send,

impl !Send for ItemKind

impl !Send for VariantKind

impl !Send for Attributes

impl !Send for Crate

impl !Send for Enum

impl !Send for Impl

impl !Send for Item

impl !Send for ItemInner

impl !Send for Module

impl !Send for Struct

impl !Send for Trait

impl !Send for TypeAlias

impl !Send for Union

impl !Send for Variant

impl !Send for Cache

impl !Send for Impl

impl !Send for Hierarchy

impl Send for Cfg

impl Send for Format

impl Send for GenericArg

impl Send for GenericArgs

impl Send for ImplKind

impl Send for ImportKind

impl Send for ItemId

impl Send for Term

impl Send for Type

impl Send for EmitType

impl Send for InputMode

impl Send for DirState

impl Send for TestFailure

impl Send for AttrKind

impl Send for ItemType

impl Send for Ending

impl Send for HrefError

impl Send for Class

impl Send for Tooltip

impl Send for ErrorCodes

impl Send for Ignore

impl Send for ItemSection

impl Send for RenderMode

impl Send for Container

impl Send for ModuleLike

impl Send for LinkFromSrc

impl Send for Res

impl Send for Suggestion

impl Send for UrlFragment

impl Send for Condition

impl Send for Argument

impl Send for Arguments

impl Send for Constant

impl Send for FnDecl

impl Send for Function

impl Send for Generics

impl Send for Import

impl Send for ItemLink

impl Send for Lifetime

impl Send for Macro

impl Send for Path

impl Send for PathSegment

impl Send for PolyTrait

impl Send for ProcMacro

impl Send for QPathData

impl Send for Span

impl Send for Static

impl Send for TraitAlias

impl Send for Options

impl Send for PathToParts

impl Send for ShouldMerge

impl Send for DocFS

impl Send for SourceInfo

impl Send for MdCollector

impl Send for Error

impl Send for Buffer

impl Send for Indent

impl Send for Decorations

impl Send for Layout

impl Send for IdMap

impl Send for Indices

impl Send for LangString

impl Send for MdRelLine

impl Send for Playground

impl Send for EscapedJson

impl Send for OrderedJson

impl Send for ImplString

impl Send for Error

impl Send for Html

impl Send for Js

impl Send for Offset

impl Send for AllTypes

impl Send for IndexItem

impl Send for ItemEntry

impl Send for ItemInfo

impl Send for RenderType

impl Send for StylePath

impl Send for AllCrates

impl Send for CrateInfo

impl Send for CratesIndex

impl Send for Implementor

impl Send for SearchIndex

impl Send for Sources

impl Send for TraitAlias

impl Send for TypeAlias

impl Send for StaticFile

impl Send for StaticFiles

impl Send for Toc

impl Send for TocBuilder

impl Send for TocEntry

impl Send for FullItemId

impl Send for ItemCount

impl Send for Tests

impl Send for Buffer

impl Send for LinkData

impl Send for Element

impl Send for Pass

impl Send for CallData

impl Send for SyntaxRange

impl Send for CssPath

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

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

impl<'a> Send for Highlight<'a>

impl<'a> Send for LangStringToken<'a>

impl<'a> Send for Line<'a>

impl<'a> Send for AssocItemLink<'a>

impl<'a> Send for AssocItemRender<'a>

impl<'a> Send for SourceContext<'a>

impl<'a> Send for ResolutionFailure<'a>

impl<'a> Send for Display<'a>

impl<'a> Send for Escape<'a>

impl<'a> Send for EscapeBodyText<'a>

impl<'a> Send for EscapeBodyTextWithWbr<'a>

impl<'a> Send for PeekIter<'a>

impl<'a> Send for TokenIter<'a>

impl<'a> Send for Page<'a>

impl<'a> Send for PageLayout<'a>

impl<'a> Send for FootnoteDef<'a>

impl<'a> Send for Markdown<'a>

impl<'a> Send for MarkdownItemInfo<'a>

impl<'a> Send for MarkdownSummaryLine<'a>

impl<'a> Send for MarkdownWithToc<'a>

impl<'a> Send for ItemVars<'a>

impl<'a> Send for Link<'a>

impl<'a> Send for LinkBlock<'a>

impl<'a> Send for Sidebar<'a>

impl<'a> Send for ScrapedInfo<'a>

impl<'a> Send for UnresolvedPath<'a>

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

impl<'a, 'b, 'ids, I> Send for HeadingLinks<'a, 'b, 'ids, I>
where I: Send,

impl<'a, 'tcx> !Send for CacheBuilder<'a, 'tcx>

impl<'a, 'tcx> !Send for HrefContext<'a, 'tcx>

impl<'a, 'tcx> !Send for TagIterator<'a, 'tcx>

impl<'a, 'tcx> !Send for LocalSourcesCollector<'a, 'tcx>

impl<'a, 'tcx> !Send for SourceCollector<'a, 'tcx>

impl<'a, 'tcx> !Send for DocTestVisibilityLinter<'a, 'tcx>

impl<'a, 'tcx> !Send for LinkCollector<'a, 'tcx>

impl<'a, 'tcx> !Send for SyntheticImplCollector<'a, 'tcx>

impl<'a, 'tcx> !Send for Linter<'a, 'tcx>

impl<'a, 'tcx> !Send for CfgPropagator<'a, 'tcx>

impl<'a, 'tcx> !Send for StabilityPropagator<'a, 'tcx>

impl<'a, 'tcx> !Send for Stripper<'a, 'tcx>

impl<'a, 'tcx> !Send for ImplStripper<'a, 'tcx>

impl<'a, 'tcx> !Send for Stripper<'a, 'tcx>

impl<'a, 'tcx> !Send for FindCalls<'a, 'tcx>

impl<'a, 'tcx> !Send for RustdocVisitor<'a, 'tcx>

impl<'a, 'tcx> !Send for LibEmbargoVisitor<'a, 'tcx>

impl<'a, 'tcx> Send for ContainerTy<'a, 'tcx>

impl<'a, 'tcx, F> !Send for TokenHandler<'a, 'tcx, F>

impl<'a, Code> Send for ScrapedSource<'a, Code>
where Code: Send,

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

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

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

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

impl<'cache> !Send for ItemAndAliasCollector<'cache>

impl<'cache, 'item> !Send for AliasedType<'cache, 'item>

impl<'cache, 'item> !Send for AliasedTypeImpl<'cache, 'item>

impl<'cx> Send for TypeLayout<'cx>

impl<'cx, 'cache, 'item> !Send for TypeImplCollector<'cx, 'cache, 'item>

impl<'hir> !Send for Module<'hir>

impl<'p, 'a, I> Send for CodeBlocks<'p, 'a, I>
where I: Send,

impl<'src> Send for Classifier<'src>

impl<'tcx> !Send for DocContext<'tcx>

impl<'tcx> !Send for EmitIgnoredResolutionErrors<'tcx>

impl<'tcx> !Send for HirCollector<'tcx>

impl<'tcx> !Send for ExtraInfo<'tcx>

impl<'tcx> !Send for Context<'tcx>

impl<'tcx> !Send for SharedContext<'tcx>

impl<'tcx> !Send for SpanMapVisitor<'tcx>

impl<'tcx> !Send for JsonRenderer<'tcx>

impl<'tcx> !Send for AliasedNonLocalStripper<'tcx>

impl<'tcx> !Send for NonLocalStripper<'tcx>

impl<'tcx> !Send for ImportStripper<'tcx>

impl<'tcx> Send for FunctionArgs<'tcx>

impl<'tcx> Send for ObjectLifetimeDefault<'tcx>

impl<Code> Send for Source<Code>
where Code: Send,

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

impl<P> Send for PartsAndLocations<P>
where P: Send,

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

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

impl Send for Abi

impl Send for GenericArg

impl Send for GenericArgs

impl Send for ItemEnum

impl Send for ItemKind

impl Send for MacroKind

impl Send for StructKind

impl Send for Term

impl Send for Type

impl Send for VariantKind

impl Send for Visibility

impl Send for Constant

impl Send for Crate

impl Send for Deprecation

impl Send for DynTrait

impl Send for Enum

impl Send for Function

impl Send for Generics

impl Send for Id

impl Send for Impl

impl Send for Item

impl Send for ItemSummary

impl Send for Module

impl Send for Path

impl Send for PolyTrait

impl Send for Primitive

impl Send for ProcMacro

impl Send for Span

impl Send for Static

impl Send for Struct

impl Send for Trait

impl Send for TraitAlias

impl Send for TypeAlias

impl Send for Union

impl Send for Use

impl Send for Variant

impl !Send for State

impl !Send for Data

impl !Send for Span

impl !Send for CodeFix

impl Send for Filter

impl Send for Error

impl Send for Diagnostic

impl Send for LineRange

impl Send for Replacement

impl Send for Snippet

impl Send for Solution

impl Send for Suggestion

impl Send for HelpOp

impl Send for Operation

impl Send for Opts

impl Send for Range

impl !Send for MacroArg

impl !Send for MacroArgKind

impl !Send for Chain

impl !Send for ChainItem

impl !Send for SubExpr

impl !Send for LineRange

impl !Send for UseSegment

impl !Send for UseTree

impl !Send for Macro

impl !Send for MacroBranch

impl !Send for ModItem

impl !Send for ParseSess

impl !Send for OutputWriter

impl !Send for FormatReport

impl Send for FileName

impl Send for ListTactic

impl Send for BraceStyle

impl Send for Color

impl Send for Density

impl Send for Edition

impl Send for EmitMode

impl Send for Heuristics

impl Send for IndentStyle

impl Send for TypeDensity

impl Send for Verbosity

impl Send for Version

impl Send for ErrorKind

impl Send for Input

impl Send for ExprType

impl Send for RhsTactics

impl Send for Timer

impl Send for BracePos

impl Send for Separator

impl Send for SpaceState

impl Send for ParserError

impl Send for DiffLine

impl Send for PathContext

impl Send for FileLines

impl Send for JsonSpan

impl Send for Range

impl Send for MacroName

impl Send for ArrayWidth

impl Send for ChainWidth

impl Send for ColorConfig

impl Send for FnCallWidth

impl Send for HardTabs

impl Send for Ignore

impl Send for IgnoreList

impl Send for MakeBackup

impl Send for MaxWidth

impl Send for TabSpaces

impl Send for Verbose

impl Send for Config

impl Send for ToTomlError

impl Send for DiffEmitter

impl Send for JsonEmitter

impl Send for ListItem

impl Send for PathVisitor

impl Send for Directory

impl Send for Mismatch

impl Send for Indent

impl Send for Shape

impl Send for SkipContext

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

impl<'a> Send for CommentStyle<'a>

impl<'a> Send for VersionChunk<'a>

impl<'a> Send for DocCommentFormatter<'a>

impl<'a> Send for CommentCodeSlices<'a>

impl<'a> Send for CommentReducer<'a>

impl<'a> Send for LineClasses<'a>

impl<'a> Send for Files<'a>

impl<'a> Send for CliConfigSetter<'a>

impl<'a> Send for ConfigSetter<'a>

impl<'a> Send for XmlEscaped<'a>

impl<'a> Send for FormattedFile<'a>

impl<'a> Send for PairParts<'a>

impl<'a> Send for VersionChunkIter<'a>

impl<'a, 'ast> !Send for SubModKind<'a, 'ast>

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

impl<'a, I, F1, F2, F3> Send for ListItems<'a, I, F1, F2, F3>
where F1: Send, F2: Send, F3: Send, I: Send, <I as Iterator>::Item: Send,

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

impl<'ast> !Send for RhsAssignKind<'ast>

impl<'ast, 'psess> !Send for ModResolver<'ast, 'psess>

impl<'b, T> !Send for Session<'b, T>

impl<'c, 'g> !Send for TyAliasRewriteInfo<'c, 'g>

impl<T> Send for CharClasses<T>
where T: Send, <T as Iterator>::Item: Send,

impl Send for FieldsShape

impl Send for FloatLength

impl Send for PassMode

impl Send for Primitive

impl Send for Scalar

impl Send for TagEncoding

impl Send for ValueAbi

impl Send for CtorKind

impl Send for ItemKind

impl Send for GlobalAlloc

impl Send for BinOp

impl Send for BorrowKind

impl Send for CastKind

impl Send for Mutability

impl Send for NullOp

impl Send for Operand

impl Send for RetagKind

impl Send for Rvalue

impl Send for Safety

impl Send for UnOp

impl Send for Variance

impl Send for MonoItem

impl Send for Endian

impl Send for Abi

impl Send for AdtKind

impl Send for AliasKind

impl Send for BoundTyKind

impl Send for ClauseKind

impl Send for ClosureKind

impl Send for DynKind

impl Send for FloatTy

impl Send for IntTy

impl Send for Movability

impl Send for Pattern

impl Send for RegionKind

impl Send for RigidTy

impl Send for TermKind

impl Send for TyConstKind

impl Send for TyKind

impl Send for UintTy

impl Send for ArgAbi

impl Send for FnAbi

impl Send for Layout

impl Send for LayoutShape

impl Send for TyAndLayout

impl Send for Attribute

impl Send for DefId

impl Send for Error

impl Send for AllocId

impl Send for BasicBlock

impl Send for Body

impl Send for LocalDecl

impl Send for Place

impl Send for SourceInfo

impl Send for Statement

impl Send for Terminator

impl Send for Instance

impl Send for InstanceDef

impl Send for StaticDef

impl Send for Location

impl Send for Crate

impl Send for CrateItem

impl Send for Opaque

impl Send for MachineInfo

impl Send for MachineSize

impl Send for AdtDef

impl Send for AliasDef

impl Send for AliasTerm

impl Send for AliasTy

impl Send for Allocation

impl Send for BoundRegion

impl Send for BoundTy

impl Send for BrNamedDef

impl Send for ClosureDef

impl Send for ConstDef

impl Send for FieldDef

impl Send for FnDef

impl Send for FnSig

impl Send for ForeignDef

impl Send for GenericArgs

impl Send for GenericDef

impl Send for Generics

impl Send for ImplDef

impl Send for LineInfo

impl Send for MirConst

impl Send for MirConstId

impl Send for ParamConst

impl Send for ParamDef

impl Send for ParamTy

impl Send for Prov

impl Send for Region

impl Send for RegionDef

impl Send for Span

impl Send for TraitDecl

impl Send for TraitDef

impl Send for TraitRef

impl Send for Ty

impl Send for TyConst

impl Send for TyConstId

impl Send for TypeAndMut

impl Send for VariantDef

impl Send for VariantIdx

impl<'a> Send for PlaceRef<'a>

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

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

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

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

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

impl Send for Error

impl Send for Status

impl Send for Version

impl Send for Directive

impl Send for LIUState

impl Send for Feature

impl<'a> Send for RevisionInfo<'a>

impl<'a> Send for ErrorAnnRev<'a>

impl<'ln> Send for HeaderLine<'ln>