Trait rustc_data_structures::sync::Send

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

Types that can be transferred across thread boundaries.

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

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

See the Nomicon and the Sync trait for more details.

Implementors§

source§

impl !Send for LocalWaker

1.26.0 · source§

impl !Send for Args

1.26.0 · source§

impl !Send for ArgsOs

source§

impl Send for DroplessArena

source§

impl Send for OwnedSlice

1.6.0 · source§

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

1.36.0 · source§

impl Send for Waker

source§

impl Send for Select<'_>

source§

impl Send for Collector

source§

impl Send for Parker

source§

impl Send for Unparker

1.44.0 · source§

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

1.44.0 · source§

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

source§

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

source§

impl<'a, 'b, K, Q, V, S, A> Send for hashbrown::map::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,

source§

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

source§

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::map::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,

1.0.0 · source§

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

1.0.0 · source§

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

1.25.0 · 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,

1.0.0 · 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,

1.0.0 · source§

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

1.0.0 · source§

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

1.0.0 · source§

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

source§

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

source§

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

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

1.0.0 · source§

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

1.0.0 · source§

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

1.0.0 · source§

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

1.0.0 · source§

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

1.28.0 · source§

impl<T> Send for NonZero<T>

1.31.0 · source§

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

1.0.0 · source§

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

1.0.0 · source§

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

1.0.0 · source§

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

1.31.0 · source§

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

1.31.0 · source§

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

1.0.0 · source§

impl<T> Send for AtomicPtr<T>

1.0.0 · source§

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

1.0.0 · source§

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

1.0.0 · source§

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

1.0.0 · 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,

1.0.0 · source§

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

1.29.0 · 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,

1.70.0 · source§

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

1.0.0 · source§

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

1.4.0 · 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,

1.0.0 · source§

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

1.6.0 · source§

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

1.6.0 · source§

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

1.0.0 · 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,

1.0.0 · source§

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

1.4.0 · 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>

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

§

impl Send for SipHasher128

§

impl Send for State

§

impl Send for SmallCStr

§

impl Send for Hash64

§

impl Send for Hash128

§

impl Send for HashingControls

§

impl Send for StableHasher

§

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<'c, G, S> Send for SccsConstruction<'c, G, S>
where G: Sync, 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<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<Ls> Send for VecLinkedListIterator<Ls>
where Ls: Send, <Ls as Links>::LinkIndex: 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> Send for rustc_data_structures::graph::scc::NodeState<N, S>
where S: Send, N: Send,

§

impl<N, S> Send for Sccs<N, S>
where S: 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 WalkReturn<S>
where S: Send,

§

impl<S> Send for SccData<S>
where S: 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<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 Element<T>
where T: Send,

§

impl<T> Send for TinyList<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,