Trait std::marker::Send

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

Types that can be transferred across thread boundaries.

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

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

See the Nomicon and the Sync trait for more details.

Implementors§

1.26.0 · source§

impl !Send for std::env::Args

1.26.0 · source§

impl !Send for ArgsOs

source§

impl Send for std::backtrace_rs::backtrace::dbghelp::Frame

source§

impl Send for Repr

1.63.0 · source§

impl Send for BorrowedHandle<'_>

Available on Windows only.
1.63.0 · source§

impl Send for HandleOrInvalid

Available on Windows only.
1.63.0 · source§

impl Send for HandleOrNull

Available on Windows only.
1.63.0 · source§

impl Send for OwnedHandle

Available on Windows only.
1.6.0 · source§

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

source§

impl Send for FindNextFileHandle

source§

impl Send for std::sys::windows::fs::OpenOptions

source§

impl Send for std::sys::windows::locks::condvar::Condvar

source§

impl Send for std::sys::windows::locks::mutex::Mutex

source§

impl Send for std::sys::windows::locks::rwlock::RwLock

source§

impl Send for StaticKey

source§

impl Send for LookupHost

1.36.0 · source§

impl Send for std::task::Waker

1.44.0 · source§

impl<'a> Send for std::io::IoSlice<'a>

1.44.0 · source§

impl<'a> Send for std::io::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 + Clone,

source§

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

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 + Clone + 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 + Clone,

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 + Clone,

source§

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

source§

impl<T> !Send for *mut Twhere 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 Rc<T>where T: ?Sized,

1.4.0 · source§

impl<T> !Send for std::rc::Weak<T>where T: ?Sized,

source§

impl<T> !Send for ReentrantMutexGuard<'_, T>

source§

impl<T> Send for &Twhere 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 Cell<T>where T: Send + ?Sized,

source§

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

source§

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

source§

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

1.31.0 · 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 std::slice::Iter<'_, T>where T: Sync,

source§

impl<T> Send for std::slice::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,

source§

impl<T> Send for AtomicPtr<T>

source§

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

1.4.0 · source§

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

1.29.0 · source§

impl<T> Send for JoinHandle<T>

source§

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

source§

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

source§

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

1.6.0 · source§

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

1.6.0 · source§

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

source§

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

source§

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

source§

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

source§

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

source§

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

source§

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

1.70.0 · source§

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

source§

impl<T: Send> Send for ReentrantMutex<T>

source§

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

source§

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

source§

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

source§

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

source§

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

impl !Send for Group

impl !Send for LexError

impl !Send for Span

impl !Send for ExpandError

impl !Send for TokenStream

impl !Send for Punct

impl Send for Buffer

impl !Send for TokenTree

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

impl !Send for Symbol

Auto implementors§

§

impl !Send for StackFrame

§

impl !Send for Dbghelp

§

impl !Send for Init

§

impl !Send for IMAGEHLP_LINEW64

§

impl !Send for MODULEENTRY32W

§

impl !Send for STACKFRAME64

§

impl !Send for STACKFRAME_EX

§

impl !Send for Vars

§

impl !Send for VarsOs

§

impl !Send for ArrayToken

§

impl !Send for ListToken

§

impl !Send for Token

§

impl !Send for std::sync::mpmc::waker::Entry

§

impl !Send for SyncWaker

§

impl !Send for std::sync::mpmc::waker::Waker

§

impl !Send for std::sync::mpmc::zero::Inner

§

impl !Send for ZeroToken

§

impl !Send for std::sync::once::OnceState

§

impl !Send for DwarfReader

§

impl !Send for Header

§

impl !Send for EXCEPTION_POINTERS

§

impl !Send for ADDRINFOA

§

impl !Send for EXCEPTION_RECORD

§

impl !Send for IO_STATUS_BLOCK

§

impl !Send for OBJECT_ATTRIBUTES

§

impl !Send for OVERLAPPED

§

impl !Send for PROCESS_INFORMATION

§

impl !Send for RTL_CONDITION_VARIABLE

§

impl !Send for RTL_SRWLOCK

§

impl !Send for SECURITY_ATTRIBUTES

§

impl !Send for STARTUPINFOW

§

impl !Send for SYSTEM_INFO

§

impl !Send for UNICODE_STRING

§

impl !Send for WSABUF

§

impl !Send for WSADATA

§

impl !Send for Module

§

impl !Send for Env

§

impl !Send for std::sys_common::once::queue::OnceState

§

impl !Send for Waiter

§

impl !Send for RawWaker

§

impl !Send for IO_STATUS_BLOCK_0

§

impl !Send for OVERLAPPED_0

§

impl !Send for RTL_RUN_ONCE

§

impl Send for AsciiChar

§

impl Send for BacktraceStatus

§

impl Send for BytesOrWide

§

impl Send for std::backtrace::Inner

§

impl Send for RawFrame

§

impl Send for PrintFmt

§

impl Send for c_void

§

impl Send for std::cmp::Ordering

§

impl Send for TryReserveErrorKind

§

impl Send for Infallible

§

impl Send for VarError

§

impl Send for std::fmt::Alignment

§

impl Send for SeekFrom

§

impl Send for ErrorKind

§

impl Send for IpAddr

§

impl Send for Ipv6MulticastScope

§

impl Send for Shutdown

§

impl Send for std::net::SocketAddr

§

impl Send for FpCategory

§

impl Send for IntErrorKind

§

impl Send for AncillaryError

§

impl Send for BacktraceStyle

§

impl Send for Hook

§

impl Send for std::path::State

§

impl Send for MustAbort

§

impl Send for Which

§

impl Send for SearchStep

§

impl Send for std::sync::atomic::Ordering

§

impl Send for Selected

§

impl Send for RecvTimeoutError

§

impl Send for TryRecvError

§

impl Send for ExclusiveState

§

impl Send for EHAction

§

impl Send for Arg

§

impl Send for Quote

§

impl Send for ReparsePoint

§

impl Send for std::sys::windows::pipe::State

§

impl Send for std::sys::windows::process::Stdio

§

impl Send for bool

§

impl Send for char

§

impl Send for f32

§

impl Send for f64

§

impl Send for i8

§

impl Send for i16

§

impl Send for i32

§

impl Send for i64

§

impl Send for i128

§

impl Send for isize

§

impl Send for str

§

impl Send for u8

§

impl Send for u16

§

impl Send for u32

§

impl Send for u64

§

impl Send for u128

§

impl Send for ()

§

impl Send for usize

§

impl Send for AllocError

§

impl Send for Global

§

impl Send for Layout

§

impl Send for LayoutError

§

impl Send for System

§

impl Send for TypeId

§

impl Send for TryFromSliceError

§

impl Send for std::ascii::EscapeDefault

§

impl Send for Backtrace

§

impl Send for BacktraceFrame

§

impl Send for BacktraceSymbol

§

impl Send for Capture

§

impl Send for LazilyResolvedCapture

§

impl Send for MyContext

§

impl Send for std::backtrace_rs::backtrace::Frame

§

impl Send for Bomb

§

impl Send for std::backtrace_rs::symbolize::Symbol

§

impl Send for ADDRESS64

§

impl Send for std::backtrace_rs::windows::CONTEXT

§

impl Send for std::backtrace_rs::windows::FLOATING_SAVE_AREA

§

impl Send for KDHELP64

§

impl Send for std::backtrace_rs::windows::M128A

§

impl Send for SYMBOL_INFOW

§

impl Send for BorrowError

§

impl Send for BorrowMutError

§

impl Send for CharTryFromError

§

impl Send for DecodeUtf16Error

§

impl Send for std::char::EscapeDebug

§

impl Send for std::char::EscapeDefault

§

impl Send for std::char::EscapeUnicode

§

impl Send for ParseCharError

§

impl Send for ToLowercase

§

impl Send for ToUppercase

§

impl Send for TryFromCharError

§

impl Send for DefaultHasher

§

impl Send for RandomState

§

impl Send for TryReserveError

§

impl Send for std::env::JoinPathsError

§

impl Send for Internal

§

impl Send for OsStr

§

impl Send for OsString

§

impl Send for CStr

§

impl Send for CString

§

impl Send for FromBytesWithNulError

§

impl Send for FromVecWithNulError

§

impl Send for IntoStringError

§

impl Send for NulError

§

impl Send for std::fmt::Error

§

impl Send for std::fs::DirBuilder

§

impl Send for std::fs::DirEntry

§

impl Send for std::fs::File

§

impl Send for std::fs::FileTimes

§

impl Send for std::fs::FileType

§

impl Send for Metadata

§

impl Send for std::fs::OpenOptions

§

impl Send for Permissions

§

impl Send for std::fs::ReadDir

§

impl Send for SipHasher

§

impl Send for BasicBlock

§

impl Send for Buffer

§

impl Send for WriterPanicked

§

impl Send for Custom

§

impl Send for std::io::error::Error

§

impl Send for SimpleMessage

§

impl Send for std::io::stdio::Stderr

§

impl Send for StderrRaw

§

impl Send for std::io::stdio::Stdin

§

impl Send for StdinRaw

§

impl Send for std::io::stdio::Stdout

§

impl Send for StdoutRaw

§

impl Send for std::io::util::Empty

§

impl Send for std::io::util::Repeat

§

impl Send for Sink

§

impl Send for Assume

§

impl Send for AddrParseError

§

impl Send for Ipv4Addr

§

impl Send for Ipv6Addr

§

impl Send for SocketAddrV4

§

impl Send for SocketAddrV6

§

impl Send for IntoIncoming

§

impl Send for std::net::tcp::TcpListener

§

impl Send for std::net::tcp::TcpStream

§

impl Send for std::net::udp::UdpSocket

§

impl Send for NonZeroI8

§

impl Send for NonZeroI16

§

impl Send for NonZeroI32

§

impl Send for NonZeroI64

§

impl Send for NonZeroI128

§

impl Send for NonZeroIsize

§

impl Send for NonZeroU8

§

impl Send for NonZeroU16

§

impl Send for NonZeroU32

§

impl Send for NonZeroU64

§

impl Send for NonZeroU128

§

impl Send for NonZeroUsize

§

impl Send for ParseFloatError

§

impl Send for ParseIntError

§

impl Send for TryFromIntError

§

impl Send for RangeFull

§

impl Send for OwnedFd

§

impl Send for FileDesc

§

impl Send for PidFd

§

impl Send for stat

§

impl Send for sockaddr

§

impl Send for sockaddr_un

§

impl Send for std::os::unix::net::addr::SocketAddr

§

impl Send for cmsghdr

§

impl Send for sockcred2

§

impl Send for ucred

§

impl Send for SocketCred

§

impl Send for UnixDatagram

§

impl Send for UnixListener

§

impl Send for UnixStream

§

impl Send for InvalidHandleError

§

impl Send for NullHandleError

§

impl Send for OwnedSocket

§

impl Send for Path

§

impl Send for PathBuf

§

impl Send for StripPrefixError

§

impl Send for Child

§

impl Send for ChildStderr

§

impl Send for ChildStdin

§

impl Send for ChildStdout

§

impl Send for std::process::Command

§

impl Send for std::process::ExitCode

§

impl Send for std::process::ExitStatus

§

impl Send for std::process::ExitStatusError

§

impl Send for Output

§

impl Send for std::process::Stdio

§

impl Send for std::ptr::Alignment

§

impl Send for ParseBoolError

§

impl Send for Utf8Error

§

impl Send for FromUtf8Error

§

impl Send for FromUtf16Error

§

impl Send for String

§

impl Send for AtomicBool

§

impl Send for AtomicI8

§

impl Send for AtomicI16

§

impl Send for AtomicI32

§

impl Send for AtomicI64

§

impl Send for AtomicIsize

§

impl Send for AtomicU8

§

impl Send for AtomicU16

§

impl Send for AtomicU32

§

impl Send for AtomicU64

§

impl Send for AtomicUsize

§

impl Send for Barrier

§

impl Send for BarrierState

§

impl Send for BarrierWaitResult

§

impl Send for std::sync::condvar::Condvar

§

impl Send for WaitTimeoutResult

§

impl Send for std::sync::mpmc::context::Context

§

impl Send for std::sync::mpmc::context::Inner

§

impl Send for Operation

§

impl Send for Backoff

§

impl Send for RecvError

§

impl Send for std::sync::once::Once

§

impl Send for Flag

§

impl Send for std::sync::poison::Guard

§

impl Send for std::sys::windows::args::Args

§

impl Send for MOUNT_POINT_REPARSE_BUFFER

§

impl Send for REPARSE_DATA_BUFFER

§

impl Send for REPARSE_MOUNTPOINT_DATA_BUFFER

§

impl Send for SOCKADDR_STORAGE_LH

§

impl Send for in6_addr

§

impl Send for in_addr

§

impl Send for ip_mreq

§

impl Send for ipv6_mreq

§

impl Send for sockaddr_in6

§

impl Send for sockaddr_in

§

impl Send for ARM64_NT_NEON128_0

§

impl Send for BY_HANDLE_FILE_INFORMATION

§

impl Send for CONSOLE_READCONSOLE_CONTROL

§

impl Send for std::sys::windows::c::windows_sys::CONTEXT

§

impl Send for CONTEXT_0_0

§

impl Send for FD_SET

§

impl Send for FILETIME

§

impl Send for FILE_ATTRIBUTE_TAG_INFO

§

impl Send for FILE_BASIC_INFO

§

impl Send for FILE_DISPOSITION_INFO

§

impl Send for FILE_DISPOSITION_INFO_EX

§

impl Send for FILE_END_OF_FILE_INFO

§

impl Send for FILE_ID_BOTH_DIR_INFO

§

impl Send for FILE_STANDARD_INFO

§

impl Send for std::sys::windows::c::windows_sys::FLOATING_SAVE_AREA

§

impl Send for GUID

§

impl Send for IN6_ADDR

§

impl Send for IN_ADDR

§

impl Send for IN_ADDR_0_0

§

impl Send for IN_ADDR_0_1

§

impl Send for IPV6_MREQ

§

impl Send for IP_MREQ

§

impl Send for LINGER

§

impl Send for std::sys::windows::c::windows_sys::M128A

§

impl Send for OVERLAPPED_0_0

§

impl Send for SOCKADDR

§

impl Send for SYSTEM_INFO_0_0

§

impl Send for TIMEVAL

§

impl Send for WIN32_FIND_DATAW

§

impl Send for WSAPROTOCOLCHAIN

§

impl Send for WSAPROTOCOL_INFOW

§

impl Send for XSAVE_FORMAT

§

impl Send for DirBuff

§

impl Send for std::sys::windows::fs::DirBuilder

§

impl Send for std::sys::windows::fs::DirEntry

§

impl Send for std::sys::windows::fs::File

§

impl Send for FileAttr

§

impl Send for FilePermissions

§

impl Send for std::sys::windows::fs::FileTimes

§

impl Send for std::sys::windows::fs::FileType

§

impl Send for std::sys::windows::fs::ReadDir

§

impl Send for Handle

§

impl Send for Socket

§

impl Send for std::sys::windows::os::JoinPathsError

§

impl Send for Buf

§

impl Send for Slice

§

impl Send for AnonPipe

§

impl Send for Pipes

§

impl Send for std::sys::windows::process::Command

§

impl Send for std::sys::windows::process::ExitCode

§

impl Send for std::sys::windows::process::ExitStatus

§

impl Send for std::sys::windows::process::ExitStatusError

§

impl Send for Process

§

impl Send for StdioPipes

§

impl Send for Handler

§

impl Send for IncompleteUtf8

§

impl Send for std::sys::windows::stdio::Stderr

§

impl Send for std::sys::windows::stdio::Stdin

§

impl Send for std::sys::windows::stdio::Stdout

§

impl Send for std::sys::windows::thread::Thread

§

impl Send for Parker

§

impl Send for PerformanceCounterInstant

§

impl Send for std::sys::windows::time::Instant

§

impl Send for std::sys::windows::time::SystemTime

§

impl Send for std::sys_common::net::TcpListener

§

impl Send for std::sys_common::net::TcpStream

§

impl Send for std::sys_common::net::UdpSocket

§

impl Send for std::sys_common::once::queue::Once

§

impl Send for CommandEnv

§

impl Send for ThreadInfo

§

impl Send for CodePoint

§

impl Send for Wtf8

§

impl Send for Wtf8Buf

§

impl Send for RawWakerVTable

§

impl Send for AccessError

§

impl Send for ScopeData

§

impl Send for Builder

§

impl Send for std::thread::Inner

§

impl Send for PanicGuard

§

impl Send for std::thread::Thread

§

impl Send for ThreadId

§

impl Send for Duration

§

impl Send for std::time::Instant

§

impl Send for std::time::SystemTime

§

impl Send for SystemTimeError

§

impl Send for TryFromFloatSecsError

§

impl Send for PhantomPinned

§

impl Send for ARM64_NT_NEON128

§

impl Send for CONTEXT_0

§

impl Send for IN6_ADDR_0

§

impl Send for IN_ADDR_0

§

impl Send for SYSTEM_INFO_0

§

impl Send for SocketAddrCRepr

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<'a> !Send for std::sys::windows::io::IoSlice<'a>

§

impl<'a> !Send for std::sys::windows::io::IoSliceMut<'a>

§

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

§

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

§

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

§

impl<'a> !Send for std::task::Context<'a>

§

impl<'a> Send for BytesOrWideString<'a>

§

impl<'a> Send for AddressKind<'a>

§

impl<'a> Send for AncillaryData<'a>

§

impl<'a> Send for Component<'a>

§

impl<'a> Send for Prefix<'a>

§

impl<'a> Send for std::backtrace_rs::symbolize::noop::Symbol<'a>

§

impl<'a> Send for OptionCppSymbol<'a>

§

impl<'a> Send for SymbolName<'a>

§

impl<'a> Send for std::env::SplitPaths<'a>

§

impl<'a> Send for BorrowedCursor<'a>

§

impl<'a> Send for std::io::Guard<'a>

§

impl<'a> Send for std::net::tcp::Incoming<'a>

§

impl<'a> Send for Messages<'a>

§

impl<'a> Send for ScmCredentials<'a>

§

impl<'a> Send for ScmRights<'a>

§

impl<'a> Send for SocketAncillary<'a>

§

impl<'a> Send for std::os::unix::net::listener::Incoming<'a>

§

impl<'a> Send for EncodeWide<'a>

§

impl<'a> Send for Location<'a>

§

impl<'a> Send for Ancestors<'a>

§

impl<'a> Send for Components<'a>

§

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

§

impl<'a> Send for std::path::Iter<'a>

§

impl<'a> Send for PrefixComponent<'a>

§

impl<'a> Send for std::process::CommandArgs<'a>

§

impl<'a> Send for CommandEnvs<'a>

§

impl<'a> Send for EscapeAscii<'a>

§

impl<'a> Send for CharSearcher<'a>

§

impl<'a> Send for std::str::Bytes<'a>

§

impl<'a> Send for CharIndices<'a>

§

impl<'a> Send for Chars<'a>

§

impl<'a> Send for EncodeUtf16<'a>

§

impl<'a> Send for std::str::EscapeDebug<'a>

§

impl<'a> Send for std::str::EscapeDefault<'a>

§

impl<'a> Send for std::str::EscapeUnicode<'a>

§

impl<'a> Send for std::str::Lines<'a>

§

impl<'a> Send for LinesAny<'a>

§

impl<'a> Send for SplitAsciiWhitespace<'a>

§

impl<'a> Send for SplitWhitespace<'a>

§

impl<'a> Send for Utf8Chunk<'a>

§

impl<'a> Send for Utf8Chunks<'a>

§

impl<'a> Send for DirBuffIter<'a>

§

impl<'a> Send for std::sys::windows::os::SplitPaths<'a>

§

impl<'a> Send for std::sys::windows::process::CommandArgs<'a>

§

impl<'a> Send for Wtf8CodePoints<'a>

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<'a, 'b> Send for CharSliceSearcher<'a, 'b>

§

impl<'a, 'b> Send for StrSearcher<'a, 'b>

§

impl<'a, 'b> Send for PrefixParserSlice<'a, 'b>

§

impl<'a, 'b, const N: usize> Send for CharArrayRefSearcher<'a, 'b, N>

§

impl<'a, 'f> !Send for VaList<'a, 'f>

§

impl<'a, A> Send for std::option::Iter<'a, A>where A: Sync,

§

impl<'a, A> Send for std::option::IterMut<'a, A>where A: Send,

§

impl<'a, B: ?Sized> Send for Cow<'a, B>where B: Sync, <B as ToOwned>::Owned: Send,

§

impl<'a, D> Send for Indented<'a, D>where D: Send,

§

impl<'a, F> Send for CharPredicateSearcher<'a, F>where F: Send,

§

impl<'a, I> Send for ByRefSized<'a, I>where I: Send,

§

impl<'a, I, A> Send for Splice<'a, I, A>where A: Send, I: Send, <I as Iterator>::Item: Send,

§

impl<'a, K> Send for std::collections::hash::set::Drain<'a, K>where K: Send,

§

impl<'a, K> Send for std::collections::hash::set::Iter<'a, K>where K: Sync,

§

impl<'a, K, F> Send for std::collections::hash::set::ExtractIf<'a, K, F>where F: Send, K: Send,

§

impl<'a, K, V> Send for std::collections::hash::map::Entry<'a, K, V>where K: Send, V: Send,

§

impl<'a, K, V> Send for std::collections::btree_map::Cursor<'a, K, V>where K: Sync, V: Sync,

§

impl<'a, K, V> Send for std::collections::btree_map::Iter<'a, K, V>where K: Sync, V: Sync,

§

impl<'a, K, V> Send for std::collections::btree_map::IterMut<'a, K, V>where K: Send, V: Send,

§

impl<'a, K, V> Send for std::collections::btree_map::Keys<'a, K, V>where K: Sync, V: Sync,

§

impl<'a, K, V> Send for std::collections::btree_map::Range<'a, K, V>where K: Sync, V: Sync,

§

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

§

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

§

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

§

impl<'a, K, V> Send for std::collections::hash::map::Drain<'a, K, V>where K: Send, V: Send,

§

impl<'a, K, V> Send for std::collections::hash::map::Iter<'a, K, V>where K: Sync, V: Sync,

§

impl<'a, K, V> Send for std::collections::hash::map::IterMut<'a, K, V>where K: Send, V: Send,

§

impl<'a, K, V> Send for std::collections::hash::map::Keys<'a, K, V>where K: Sync, V: Sync,

§

impl<'a, K, V> Send for std::collections::hash::map::OccupiedEntry<'a, K, V>where K: Send, V: Send,

§

impl<'a, K, V> Send for std::collections::hash::map::OccupiedError<'a, K, V>where K: Send, V: Send,

§

impl<'a, K, V> Send for std::collections::hash::map::VacantEntry<'a, K, V>where K: Send, V: Send,

§

impl<'a, K, V> Send for std::collections::hash::map::Values<'a, K, V>where K: Sync, V: Sync,

§

impl<'a, K, V> Send for std::collections::hash::map::ValuesMut<'a, K, V>where K: Send, V: Send,

§

impl<'a, K, V, A> Send for std::collections::btree_map::Entry<'a, K, V, A>where A: Send, K: Send, V: Send,

§

impl<'a, K, V, A> Send for std::collections::btree_map::CursorMut<'a, K, V, A>where A: Send, K: Send, V: Send,

§

impl<'a, K, V, A> Send for std::collections::btree_map::OccupiedEntry<'a, K, V, A>where A: Send, K: Send, V: Send,

§

impl<'a, K, V, A> Send for std::collections::btree_map::OccupiedError<'a, K, V, A>where A: Send, K: Send, V: Send,

§

impl<'a, K, V, A> Send for std::collections::btree_map::VacantEntry<'a, K, V, A>where A: Send, K: Send, V: Send,

§

impl<'a, K, V, F> Send for std::collections::hash::map::ExtractIf<'a, K, V, F>where F: Send, K: Send, V: Send,

§

impl<'a, K, V, F, A> Send for std::collections::btree_map::ExtractIf<'a, K, V, F, A>where A: Send, F: Send, K: Send, V: Send,

§

impl<'a, K, V, S> Send for RawEntryMut<'a, K, V, S>where K: Send, S: Send + Sync, V: Send,

§

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

§

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

§

impl<'a, K, V, S> Send for std::collections::hash::map::RawOccupiedEntryMut<'a, K, V, S>where K: Send, S: Send, V: Send,

§

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

§

impl<'a, P> Send for MatchIndices<'a, P>where <P as Pattern<'a>>::Searcher: Send,

§

impl<'a, P> Send for Matches<'a, P>where <P as Pattern<'a>>::Searcher: Send,

§

impl<'a, P> Send for RMatchIndices<'a, P>where <P as Pattern<'a>>::Searcher: Send,

§

impl<'a, P> Send for RMatches<'a, P>where <P as Pattern<'a>>::Searcher: Send,

§

impl<'a, P> Send for std::str::RSplit<'a, P>where <P as Pattern<'a>>::Searcher: Send,

§

impl<'a, P> Send for std::str::RSplitN<'a, P>where <P as Pattern<'a>>::Searcher: Send,

§

impl<'a, P> Send for RSplitTerminator<'a, P>where <P as Pattern<'a>>::Searcher: Send,

§

impl<'a, P> Send for std::str::Split<'a, P>where <P as Pattern<'a>>::Searcher: Send,

§

impl<'a, P> Send for std::str::SplitInclusive<'a, P>where <P as Pattern<'a>>::Searcher: Send,

§

impl<'a, P> Send for std::str::SplitN<'a, P>where <P as Pattern<'a>>::Searcher: Send,

§

impl<'a, P> Send for SplitTerminator<'a, P>where <P as Pattern<'a>>::Searcher: Send,

§

impl<'a, T> !Send for std::sync::mpsc::Iter<'a, T>

§

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

§

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

§

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

§

impl<'a, T> Send for std::collections::btree_set::Range<'a, T>where T: Sync,

§

impl<'a, T> Send for std::collections::btree_set::SymmetricDifference<'a, T>where T: Sync,

§

impl<'a, T> Send for std::collections::btree_set::Union<'a, T>where T: Sync,

§

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

§

impl<'a, T> Send for std::collections::vec_deque::IterMut<'a, T>where T: Send,

§

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

§

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

§

impl<'a, T> Send for std::result::IterMut<'a, T>where T: Send,

§

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

§

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

§

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

§

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

§

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

§

impl<'a, T, A> Send for std::collections::binary_heap::Drain<'a, T, A>where A: Send, T: Send,

§

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

§

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

§

impl<'a, T, A> Send for std::collections::btree_set::Difference<'a, T, A>where A: Sync, T: Sync,

§

impl<'a, T, A> Send for std::collections::btree_set::Intersection<'a, T, A>where A: Sync, T: Sync,

§

impl<'a, T, F, A = Global> !Send for std::collections::linked_list::ExtractIf<'a, T, F, A>

§

impl<'a, T, F, A> Send for std::collections::btree_set::ExtractIf<'a, T, F, A>where A: Send, F: Send, T: Send,

§

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

§

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

§

impl<'a, T, P> Send for GroupByMut<'a, T, P>where P: Send, T: Send,

§

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

§

impl<'a, T, P> Send for RSplitMut<'a, T, P>where P: Send, T: Send,

§

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

§

impl<'a, T, P> Send for RSplitNMut<'a, T, P>where P: Send, T: Send,

§

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

§

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

§

impl<'a, T, P> Send for SplitInclusiveMut<'a, T, P>where P: Send, T: Send,

§

impl<'a, T, P> Send for SplitMut<'a, T, P>where P: Send, T: Send,

§

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

§

impl<'a, T, P> Send for SplitNMut<'a, T, P>where P: Send, T: Send,

§

impl<'a, T, S> Send for std::collections::hash::set::Difference<'a, T, S>where S: Sync, T: Sync,

§

impl<'a, T, S> Send for std::collections::hash::set::Intersection<'a, T, S>where S: Sync, T: Sync,

§

impl<'a, T, S> Send for std::collections::hash::set::SymmetricDifference<'a, T, S>where S: Sync, T: Sync,

§

impl<'a, T, S> Send for std::collections::hash::set::Union<'a, T, S>where S: Sync, T: Sync,

§

impl<'a, T, const N: usize> !Send for ArrayWindows<'a, T, N>

§

impl<'a, T, const N: usize> Send for std::slice::ArrayChunks<'a, T, N>where T: Sync,

§

impl<'a, T, const N: usize> Send for ArrayChunksMut<'a, T, N>where T: Send,

§

impl<'a, W: ?Sized> Send for LineWriterShim<'a, W>where W: Send,

§

impl<'a, const LEN: usize> Send for PrefixParser<'a, LEN>

§

impl<'a, const N: usize> Send for CharArraySearcher<'a, N>

§

impl<'b, T> !Send for Ref<'b, T>

§

impl<'b, T> !Send for RefMut<'b, T>

§

impl<'data> Send for BorrowedBuf<'data>

§

impl<'f> !Send for VaListImpl<'f>

§

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

§

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

§

impl<'scope, 'env> Send for Scope<'scope, 'env>

§

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

§

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

§

impl<'scope, T> Send for std::thread::Packet<'scope, T>where T: Send,

§

impl<'socket> Send for BorrowedSocket<'socket>

§

impl<A> Send for std::iter::Repeat<A>where A: Send,

§

impl<A> Send for std::option::IntoIter<A>where A: Send,

§

impl<A, B> Send for std::iter::Chain<A, B>where A: Send, B: Send,

§

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

§

impl<B> Send for std::io::Lines<B>where B: Send,

§

impl<B> Send for std::io::Split<B>where B: Send,

§

impl<B, C> Send for ControlFlow<B, C>where B: Send, C: Send,

§

impl<C> !Send for std::sync::mpmc::counter::Receiver<C>

§

impl<C> !Send for std::sync::mpmc::counter::Sender<C>

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<H> Send for BuildHasherDefault<H>

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<I> Send for Flatten<I>where I: Send, <<I as Iterator>::Item as IntoIterator>::IntoIter: Send,

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<I, U, F> Send for FlatMap<I, U, F>where F: Send, I: Send, <U as IntoIterator>::IntoIter: Send,

§

impl<I, const N: usize> Send for std::iter::ArrayChunks<I, N>where I: Send, <I as Iterator>::Item: Send,

§

impl<Idx> Send for std::ops::Range<Idx>where Idx: Send,

§

impl<Idx> Send for RangeFrom<Idx>where Idx: Send,

§

impl<Idx> Send for RangeInclusive<Idx>where Idx: Send,

§

impl<Idx> Send for RangeTo<Idx>where Idx: Send,

§

impl<Idx> Send for RangeToInclusive<Idx>where Idx: Send,

§

impl<K> Send for std::collections::hash::set::IntoIter<K>where K: Send,

§

impl<K, V> Send for std::collections::hash::map::IntoIter<K, V>where K: Send, V: Send,

§

impl<K, V> Send for std::collections::hash::map::IntoKeys<K, V>where K: Send, V: Send,

§

impl<K, V> Send for std::collections::hash::map::IntoValues<K, V>where K: Send, V: Send,

§

impl<K, V, A> Send for std::collections::btree_map::IntoIter<K, V, A>where A: Send, K: Send, V: Send,

§

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

§

impl<K, V, A> Send for std::collections::btree_map::IntoValues<K, V, A>where A: Send, K: Send, V: Send,

§

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

§

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

§

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

§

impl<R> Send for std::io::Bytes<R>where R: Send,

§

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

§

impl<Ret, T> Send for fn (T₁, T₂, …, Tₙ) -> Ret

§

impl<T> !Send for ReceiverFlavor<T>

§

impl<T> !Send for SenderFlavor<T>

§

impl<T> !Send for UniqueRc<T>

§

impl<T> !Send for std::sync::mpmc::array::Channel<T>

§

impl<T> !Send for std::sync::mpmc::list::Channel<T>

§

impl<T> !Send for std::sync::mpmc::zero::Channel<T>

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<T> Send for [T]where T: Send,

§

impl<T> Send for (T₁, T₂, …, Tₙ)where T: Send,

§

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

§

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

§

impl<T> Send for Pending<T>

§

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

§

impl<T> Send for std::io::cursor::Cursor<T>where T: Send,

§

impl<T> Send for std::io::Take<T>where T: Send,

§

impl<T> Send for std::iter::Empty<T>

§

impl<T> Send for std::iter::Once<T>where T: Send,

§

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

§

impl<T> Send for Discriminant<T>

§

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

§

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

§

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

§

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

§

impl<T> Send for std::result::IntoIter<T>where T: Send,

§

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

§

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

§

impl<T> Send for Position<T>

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<T> Send for LocalKey<T>

§

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

§

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

§

impl<T, A> Send for std::collections::binary_heap::IntoIter<T, A>where A: Send, T: Send,

§

impl<T, A> Send for IntoIterSorted<T, A>where A: Send, T: Send,

§

impl<T, A> Send for std::collections::btree_set::IntoIter<T, A>where A: Send, T: Send,

§

impl<T, A> Send for std::collections::linked_list::IntoIter<T, A>where A: Send, T: Send,

§

impl<T, A> Send for BTreeSet<T, A>where A: Send, T: Send,

§

impl<T, A> Send for BinaryHeap<T, A>where A: Send, T: Send,

§

impl<T, A> Send for VecDeque<T, A>where A: Send, T: Send,

§

impl<T, A> Send for std::collections::vec_deque::IntoIter<T, A>where A: Send, T: Send,

§

impl<T, A> Send for Vec<T, A>where A: Send, T: Send,

§

impl<T, E> Send for Result<T, E>where E: Send, T: Send,

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<T, const LANES: usize> Send for Mask<T, LANES>where T: Send,

§

impl<T, const N: usize> Send for [T; N]where T: Send,

§

impl<T, const N: usize> Send for std::array::IntoIter<T, N>where T: Send,

§

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

§

impl<T, const N: usize> Send for [MaybeUninit<T>; N]where T: Send,

§

impl<T: ?Sized> Send for SyncUnsafeCell<T>where T: Send,

§

impl<T: ?Sized> Send for UnsafeCell<T>where T: Send,

§

impl<T: ?Sized> Send for ManuallyDrop<T>where T: Send,

§

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

§

impl<T: ?Sized> Send for Align8<T>where T: Send,

§

impl<T: ?Sized> Send for PhantomData<T>where T: Send,

§

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

§

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

§

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

§

impl<W: ?Sized> Send for LineWriter<W>where W: Send,

§

impl<Y, R> Send for GeneratorState<Y, R>where R: Send, Y: Send,

§

impl<const LANES: usize> Send for LaneCount<LANES>

§

impl<const N: usize> Send for [u8; N]

impl Send for U64x2

impl Send for Result

impl Send for Options

impl Send for Name

impl Send for HasArg

impl Send for Occur

impl Send for Opt

impl Send for OptGroup

impl Send for Optval

impl Send for Matches

impl Send for Fail

impl Send for max_align_t

impl Send for timezone

impl Send for stat

impl Send for utimbuf

impl Send for tm

impl Send for timeval

impl Send for timespec

impl Send for sockaddr

impl Send for FILE

impl Send for fpos_t

impl !Send for Arena

impl<S> Send for HandleStore<S>where <S as Types>::FreeFunctions: Send, <S as Types>::SourceFile: Send, <S as Types>::Span: Send, <S as Types>::TokenStream: Send,

impl !Send for TokenStream

impl !Send for SourceFile

impl !Send for Span

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

impl<I, O> Send for Client<I, O>

impl Send for ProcMacro

impl<'a, A, R> !Send for Closure<'a, A, R>

impl Send for Env

impl Send for FxHasher

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

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

impl<'a, 'b, T> Send for RefMutL<'a, 'b, T>where <T as ApplyL<'b>>::Out: Send,

impl<T> Send for ScopedCell<T>where <T as ApplyL<'static>>::Out: Send,

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

impl<S> Send for Dispatcher<S>where S: Send, <S as Types>::FreeFunctions: Send, <S as Types>::SourceFile: Send, <S as Types>::Span: Send, <S as Types>::TokenStream: Send,

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

impl Send for SameThread

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

impl !Send for Interner

impl Send for TokenStream

impl Send for SourceFile

impl Send for Span

impl Send for Symbol

impl Send for Method

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

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

impl Send for LitKind

impl<Span> Send for DelimSpan<Span>where Span: Send,

impl<TokenStream, Span> Send for Group<TokenStream, Span>where Span: Send, TokenStream: Send,

impl<Span> Send for Punct<Span>where Span: Send,

impl<Span, Symbol> Send for Ident<Span, Symbol>where Span: Send, Symbol: Send,

impl<Span, Symbol> Send for Literal<Span, Symbol>where Span: Send, Symbol: Send,

impl<TokenStream, Span, Symbol> Send for TokenTree<TokenStream, Span, Symbol>where Span: Send, Symbol: Send, TokenStream: Send,

impl<Span> Send for Diagnostic<Span>where Span: Send,

impl<Span> Send for ExpnGlobals<Span>where Span: Send,

impl Send for Level

impl !Send for Diagnostic

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

impl !Send for IntoIter

impl !Send for SourceFile

impl Send for Delimiter

impl Send for Spacing

impl !Send for Ident

impl !Send for Literal

impl<'a> Send for Demangle<'a>

impl<'a> Send for Demangle<'a>

impl Send for ParseError

impl<'s> Send for Ident<'s>

impl<'s> Send for HexNibbles<'s>

impl<'s> Send for Parser<'s>

impl<'a, 'b, 's> !Send for Printer<'a, 'b, 's>

impl<'a> Send for Demangle<'a>

impl<'a> Send for DemangleStyle<'a>

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

impl Send for Initializer

impl Send for Cache

impl Send for TestOpts

impl Send for Metric

impl Send for MetricMap

impl Send for Options

impl Send for RunIgnored

impl Send for RunStrategy

impl Send for ShouldPanic

impl Send for TestResult

impl Send for TestDesc

impl Send for TestId

impl Send for TestName

impl Send for TestType

impl Send for Bencher

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

impl Send for TestEvent

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

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

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

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

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

impl Send for Rng

impl Send for BenchMode

impl Send for ColorConfig

impl Send for Summary

impl Send for States

impl Send for FormatState

impl Send for Param

impl Send for Variables

impl Send for Flags

impl Send for FormatOp

impl Send for TermInfo

impl Send for Error

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

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

impl Send for SMALL_RECT

impl Send for COORD

impl Send for NamePadding

impl Send for TestFn

impl Send for Runnable