Trait otter_api_tests::imports::failure::_core::marker::Send1.0.0[][src]

pub unsafe auto trait Send { }

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 for more details.

Implementations on Foreign Types

impl<'de, T: ?Sized> Send for Borrowed<'de, T> where
    T: Sync

impl<'a, E> Send for StrDeserializer<'a, E> where
    E: Send

impl<'de, E> Send for BorrowedStrDeserializer<'de, E> where
    E: Send

impl<'a, 'de, E> Send for FlatMapDeserializer<'a, 'de, E> where
    E: Send

impl<'a, 'de, E> Send for FlatMapAccess<'a, 'de, E> where
    E: Send

impl<'a, 'de, E> Send for FlatStructAccess<'a, 'de, E> where
    E: Send

impl<'a, 'de, E> Send for FlatInternallyTaggedAccess<'a, 'de, E> where
    E: Send

impl<'de> Send for Content<'de>

impl<'de, E> Send for ContentDeserializer<'de, E> where
    E: Send

impl<'a, 'de, E> Send for ContentRefDeserializer<'a, 'de, E> where
    E: Send

impl<'de, E> Send for EnumDeserializer<'de, E> where
    E: Send

impl<'a> Send for InternallyTaggedUnitVisitor<'a>

impl Send for TagContentOtherField

impl Send for TagContentOtherFieldVisitor

impl Send for TagOrContentField

impl Send for TagOrContentFieldVisitor

impl<'de, T> Send for TaggedContentVisitor<'de, T> where
    T: Send

impl<'a> Send for UntaggedUnitVisitor<'a>

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

impl<'a, M> Send for FlatMapSerializer<'a, M> where
    M: Send

impl<'a, M> Send for FlatMapSerializeMap<'a, M> where
    M: Send

impl<'a, M> Send for FlatMapSerializeStruct<'a, M> where
    M: Send

impl<'a, M> Send for FlatMapSerializeStructVariantAsMapValue<'a, M> where
    M: Send

impl Send for Argument

impl Send for FormatSpec

impl Send for Alignment

impl Send for Count

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

impl Send for Big32x40

impl Send for Big8x3

impl Send for Sign

impl<'a> Send for Decimal<'a>

impl<'a> Send for ParseResult<'a>

impl Send for Unpacked

impl Send for Decoded

impl Send for FullDecoded

impl<'a> Send for Part<'a>

impl<'a> Send for Formatted<'a>

impl Send for Sign

impl<T> Send for Lazy<T> where
    T: Send

impl Send for Compiler

impl Send for Exec

impl Send for ExecBuilder

impl Send for Char

impl<'t> Send for CharInput<'t>

impl Send for InputAt

impl Send for LiteralSearcher

impl Send for EmptyLook

impl Send for Inst

impl Send for InstRanges

impl Send for Program

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

impl<T> Send for Mutex<T> where
    T: Send + ?Sized
[src]

impl Send for Once[src]

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

impl<T> Send for RwLock<T> where
    T: Send + ?Sized
[src]

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

impl<T> Send for SyncOnceCell<T> where
    T: Send
[src]

impl<T> !Send for *const T where
    T: ?Sized
[src]

impl<'_, T> Send for &'_ T where
    T: Sync + ?Sized
[src]

impl<T> !Send for *mut T where
    T: ?Sized
[src]

impl<'_, T> Send for &'_ mut T where
    T: Send + ?Sized
[src]

impl<'_, T> Send for IterMut<'_, T> where
    T: Send
[src]

impl<'_, T> Send for Cursor<'_, T> where
    T: Sync
[src]

impl<'_, T> Send for Drain<'_, T> where
    T: Send
[src]

impl<T> !Send for Rc<T> where
    T: ?Sized
[src]

impl<T> Send for LinkedList<T> where
    T: Send
[src]

impl<T> Send for Weak<T> where
    T: Sync + Send + ?Sized
[src]

impl<'_> Send for Drain<'_>[src]

impl<T, A> Send for IntoIter<T, A> where
    T: Send,
    A: Allocator + Send
[src]

impl<'_, T> Send for Iter<'_, T> where
    T: Sync
[src]

impl<'_, T> Send for IterMut<'_, T> where
    T: Send
[src]

impl<'_, T, A> Send for Drain<'_, T, A> where
    T: Send,
    A: Send + Allocator
[src]

impl<T> !Send for Weak<T> where
    T: ?Sized
[src]

impl<'_, T> Send for CursorMut<'_, T> where
    T: Send
[src]

impl Send for RawEvent

impl Send for Registration[src]

impl Send for SetReadiness[src]

impl<T> Send for AtomicLazyCell<T> where
    T: Send

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

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

impl Send for isize

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

impl Send for [u8]

impl Send for char

impl Send for u128

impl Send for u16

impl Send for i128

impl Send for i16

impl Send for str

impl Send for f64

impl Send for u64

impl Send for u8

impl Send for i64

impl Send for i8

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

impl Send for bool

impl Send for f32

impl Send for u32

impl Send for usize

impl Send for i32

Loading content...

Implementors

impl !Send for Args1.26.0[src]

impl !Send for ArgsOs1.26.0[src]

impl Send for ZCoord

impl Send for Dir

impl Send for Waker1.36.0[src]

impl<'_, T> Send for otter_api_tests::imports::failure::_core::slice::Iter<'_, T> where
    T: Sync
[src]

impl<'_, T> Send for otter_api_tests::imports::failure::_core::slice::IterMut<'_, T> where
    T: Send
[src]

impl<'a> Send for IoSlice<'a>1.44.0[src]

impl<'a> Send for IoSliceMut<'a>1.44.0[src]

impl<'a, A> Send for otter_api_tests::imports::otter_base::imports::arrayvec::Drain<'a, A> where
    A: Array + Send
[src]

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

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

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

impl<Dyn> Send for DynMetadata<Dyn> where
    Dyn: ?Sized
[src]

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

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

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

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

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

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

impl<T> !Send for NonNull<T> where
    T: ?Sized
1.25.0[src]

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

impl<T> Send for otter_api_tests::iter::Empty<T>1.42.0[src]

impl<T> Send for Receiver<T> where
    T: Send
[src]

impl<T> Send for Sender<T> where
    T: Send
[src]

impl<T> Send for SyncSender<T> where
    T: Send
[src]

impl<T> Send for Arc<T> where
    T: Sync + Send + ?Sized
[src]

impl<T> Send for RefCell<T> where
    T: Send + ?Sized
[src]

impl<T> Send for JoinHandle<T>1.29.0[src]

impl<T> Send for Cell<T> where
    T: Send + ?Sized
[src]

impl<T> Send for AtomicPtr<T>[src]

impl<Tz> Send for Date<Tz> where
    Tz: TimeZone,
    <Tz as TimeZone>::Offset: Send
[src]

impl<Tz> Send for DateTime<Tz> where
    Tz: TimeZone,
    <Tz as TimeZone>::Offset: Send
[src]

Loading content...

Auto implementors

impl !Send for Vars

impl !Send for VarsOs

impl !Send for AccountsGuard

impl !Send for MgmtChannel

impl !Send for MgmtChannelForGame

impl !Send for SetupCore

impl !Send for otter_api_tests::imports::env_logger::fmt::Formatter

impl !Send for Style

impl !Send for Dl_info

impl !Send for addrinfo

impl !Send for aiocb

impl !Send for dl_phdr_info

impl !Send for ff_periodic_effect

impl !Send for glob64_t

impl !Send for glob_t

impl !Send for group

impl !Send for hostent

impl !Send for if_nameindex

impl !Send for ifaddrs

impl !Send for iovec

impl !Send for lconv

impl !Send for mcontext_t

impl !Send for mmsghdr

impl !Send for mntent

impl !Send for passwd

impl !Send for posix_spawn_file_actions_t

impl !Send for protoent

impl !Send for regex_t

impl !Send for rtentry

impl !Send for servent

impl !Send for sigevent

impl !Send for sigval

impl !Send for spwd

impl !Send for stack_t

impl !Send for tm

impl !Send for ucontext_t

impl !Send for user

impl !Send for InterfaceAddressIterator

impl !Send for SigEvent

impl !Send for msghdr

impl !Send for UContext

impl !Send for GuardNoSend

impl !Send for TraitObject

impl !Send for RawWaker

impl Send for AccountScope

impl Send for AccountsSaveError

impl Send for AggregatedIE

impl Send for ApiPieceOpError

impl Send for InternalError

impl Send for InvalidScopedName

impl Send for LinkKind

impl Send for MgmtChannelReadError

impl Send for OccDisplacement

impl Send for OccultationKindAlwaysOk

impl Send for OldNewIndex

impl Send for OnlineError

impl Send for Outline

impl Send for PieceAngle

impl Send for PieceMoveable

impl Send for PieceOpError

impl Send for PieceOpErrorPartiallyProcessed

impl Send for PieceUpdateOps

impl Send for PreparedUpdateEntry

impl Send for PresentationLayout

impl Send for SVGProcessingError

impl Send for SpecError

impl Send for StaticUser

impl Send for TablePermission

impl Send for TablePlayerSpec

impl Send for UoKind

impl Send for WhatResponseToClientOp

impl Send for VarError

impl Send for AdaptiveFormat

impl Send for Age

impl Send for Cleanup

impl Send for Criterion

impl Send for Duplicate

impl Send for FlexiLoggerError

impl Send for Level

impl Send for LevelFilter

impl Send for LogTarget

impl Send for Naming

impl Send for otter_api_tests::fmt::Alignment

impl Send for RecvTimeoutError

impl Send for TryRecvError

impl Send for otter_api_tests::serde_json::Value

impl Send for Category

impl Send for CharEscape

impl Send for Config1

impl Send for ErrorKind

impl Send for Infallible

impl Send for LibraryLoadError

impl Send for MgmtCommand

impl Send for MgmtError

impl Send for MgmtGameInstruction

impl Send for MgmtGameResponse

impl Send for MgmtGameUpdateMode

impl Send for MgmtResponse

impl Send for OccultationMethod

impl Send for otter_api_tests::shapelib::Ordering

impl Send for SeekFrom

impl Send for Void

impl Send for DiffToShow

impl Send for PieceLabelPlace

impl Send for otter_api_tests::shapelib::toml_de::Error

impl Send for SearchStep

impl Send for FchownatFlags

impl Send for ForkResult

impl Send for LinkatFlags

impl Send for PathconfVar

impl Send for SysconfVar

impl Send for UnlinkatFlags

impl Send for Whence

impl Send for AncillaryError

impl Send for LogicError

impl Send for Month

impl Send for RoundingError

impl Send for SecondsFormat

impl Send for Weekday

impl Send for Fixed

impl Send for Numeric

impl Send for Pad

impl Send for Tz

impl Send for Target

impl Send for TimestampPrecision

impl Send for WriteStyle

impl Send for Color

impl Send for DIR

impl Send for FILE

impl Send for c_void

impl Send for fpos64_t

impl Send for fpos_t

impl Send for timezone

impl Send for Type

impl Send for otter_api_tests::imports::nix::Error

impl Send for Errno

impl Send for FlockArg

impl Send for PosixFadviseAdvice

impl Send for AioCancelStat

impl Send for AioFsyncMode

impl Send for LioMode

impl Send for LioOpcode

impl Send for EpollOp

impl Send for MmapAdvise

impl Send for Event

impl Send for Request

impl Send for QuotaFmt

impl Send for QuotaType

impl Send for RebootMode

impl Send for SigHandler

impl Send for SigevNotify

impl Send for SigmaskHow

impl Send for Signal

impl Send for AddressFamily

impl Send for ControlMessageOwned

impl Send for InetAddr

impl Send for IpAddr

impl Send for Shutdown

impl Send for SockAddr

impl Send for SockProtocol

impl Send for otter_api_tests::imports::nix::sys::socket::SockType

impl Send for FchmodatFlags

impl Send for UtimensatFlags

impl Send for BaudRate

impl Send for FlowArg

impl Send for FlushArg

impl Send for SetArg

impl Send for SpecialCharacterIndices

impl Send for otter_api_tests::imports::nix::sys::timerfd::ClockId

impl Send for Expiration

impl Send for WaitStatus

impl Send for DecodeErrKind

impl Send for OnceState

impl Send for PwdError

impl Send for otter_api_tests::imports::regex::Error

impl Send for otter_api_tests::imports::rmp_serde::decode::Error

impl Send for otter_api_tests::imports::rmp_serde::encode::Error

impl Send for otter_api_tests::imports::toml::Value

impl Send for otter_api_tests::imports::toml::ser::Error

impl Send for ConnCredentials

impl Send for FpCategory

impl Send for IntErrorKind

impl Send for otter_api_tests::imports::failure::_core::sync::atomic::Ordering

impl Send for AuthorisationError

impl Send for otter_api_tests::authproofs::Global

impl Send for Handle

impl Send for JoinPathsError

impl Send for DeferredNow

impl Send for LogSpecBuilder

impl Send for otter_api_tests::flexi_logger::Logger

impl Send for LoggerHandle

impl Send for ModuleFilter

impl Send for FileLogWriter

impl Send for FileLogWriterBuilder

impl Send for otter_api_tests::fmt::Error

impl Send for DirBuilder

impl Send for DirEntry

impl Send for FileType

impl Send for otter_api_tests::fs::Metadata

impl Send for OpenOptions

impl Send for Permissions

impl Send for ReadDir

impl Send for PosCFromIteratorError

impl Send for DefaultHasher

impl Send for RandomState

impl Send for otter_api_tests::io::Empty

impl Send for otter_api_tests::io::Error

impl Send for Initializer

impl Send for otter_api_tests::io::Repeat

impl Send for Sink

impl Send for Stderr

impl Send for Stdin

impl Send for Stdout

impl Send for RecvError

impl Send for otter_api_tests::serde_json::map::IntoIter

impl Send for CompactFormatter

impl Send for otter_api_tests::serde_json::Error

impl Send for Number

impl Send for otter_api_tests::serde_json::value::Serializer

impl Send for Ent

impl Send for PlHeld

impl Send for PlHist

impl Send for Posx

impl Send for Deck

impl Send for Disc

impl Send for Hand

impl Send for OwnedCommon

impl Send for PieceLabel

impl Send for PlayerLabel

impl Send for Rect

impl Send for UpdateId

impl Send for AccessTokenInfo

impl Send for AccessTokenReport

impl Send for Alphanumeric

impl Send for Child

impl Send for Command

impl Send for Condvar

impl Send for Contents

impl Send for CoordinateOverflow

impl Send for DescId

impl Send for otter_api_tests::shapelib::Duration

impl Send for Explicit1

impl Send for File

impl Send for FileData

impl Send for GroupData

impl Send for GroupDefn

impl Send for GroupDetails

impl Send for Instant

impl Send for otter_api_tests::shapelib::Item

impl Send for ItemEnquiryData

impl Send for ItemSpec

impl Send for LogSpecification

impl Send for MultiSpec

impl Send for NonZeroUsize

impl Send for OsStr

impl Send for PathBuf

impl Send for RecolourData

impl Send for otter_api_tests::shapelib::Regex

impl Send for Registry

impl Send for Stdio

impl Send for SvgId

impl Send for TimeSpec

impl Send for TryFromIntError

impl Send for Uid

impl Send for UnixStream

impl Send for Url

impl Send for ParseBoolError

impl Send for Utf8Error

impl Send for AbbrevPresentationLayout

impl Send for AccessRecord

impl Send for AccountId

impl Send for AccountName

impl Send for AccountNotFound

impl Send for AccountRecord

impl Send for Accounts

impl Send for CircleShape

impl Send for Client

impl Send for ClientId

impl Send for ClientSequence

impl Send for ColourSpec

impl Send for CommittedLogEntry

impl Send for CompassAngle

impl Send for Data

impl Send for DataLoadPlayer

impl Send for DirSubst

impl Send for ExecuteGameChangeUpdates

impl Send for ExitStatusError

impl Send for FaceId

impl Send for FakeRngSpec

impl Send for FixedToken

impl Send for FooParseError

impl Send for GLOBAL

impl Send for GPiece

impl Send for GPieces

impl Send for GPlayer

impl Send for GameBeingDestroyed

impl Send for GameOccults

impl Send for GameSpec

impl Send for GameState

impl Send for Generation

impl Send for otter_api_tests::Global

impl Send for GoodItemName

impl Send for Html

impl Send for HtmlLit

impl Send for HtmlStr

impl Send for IOccults

impl Send for IPiece

impl Send for IPieceTraitObj

impl Send for IPieces

impl Send for IPlayer

impl Send for otter_api_tests::Instance

impl Send for otter_api_tests::Instance

impl Send for InstanceContainer

impl Send for InstanceName

impl Send for InstanceRef

impl Send for InstanceWeakRef

impl Send for InternalLogicError

impl Send for LinksTable

impl Send for LogEntry

impl Send for ModifyingPieces

impl Send for NascentOccultation

impl Send for Notch

impl Send for Notches

impl Send for OccId

impl Send for OccultIlkData

impl Send for OccultIlkId

impl Send for OccultIlkName

impl Send for OccultIlkOwningId

impl Send for OccultIlks

impl Send for OccultView

impl Send for Occultation

impl Send for OccultationViews

impl Send for OcculterRotationChecked

impl Send for Opts

impl Send for OtterPauseable

impl Send for OtterPaused

impl Send for OwnerOccultationView

impl Send for PerPlayerIdMap

impl Send for PieceAliases

impl Send for PieceId

impl Send for PieceLabelLoaded

impl Send for PieceOccult

impl Send for PieceRenderInstructions

impl Send for PieceSpecLoaded

impl Send for PieceUpdate

impl Send for PiecesSpec

impl Send for PlayerAccessUnset

impl Send for PlayerId

impl Send for PlayerNotFound

impl Send for PlayerRecord

impl Send for PlayerUpdates

impl Send for PlayerUpdatesBuildContext

impl Send for PreparedPieceImage

impl Send for PreparedPieceState

impl Send for PreparedUpdate

impl Send for PreparedUpdateEntry_Image

impl Send for PreparedUpdateEntry_Piece

impl Send for PrivateCaller

impl Send for RawToken

impl Send for RawTokenVal

impl Send for RectShape

impl Send for RngWrap

impl Send for ServerConfig

impl Send for ServerConfigSpec

impl Send for ShowUnocculted

impl Send for SimpleCommon

impl Send for StaticUserIter

impl Send for StaticUserSetup

impl Send for Subst

impl Send for TableSpec

impl Send for otter_api_tests::Timestamp

impl Send for Timezone

impl Send for ToRecalculate

impl Send for TokenByEmail

impl Send for TokenDeliveryError

impl Send for TokenRevelationKey

impl Send for TokenRevelationValue

impl Send for TrackWantedTests

impl Send for UniformOccultationView

impl Send for UnsupportedColourSpec

impl Send for UoDescription

impl Send for UrlOnStdout

impl Send for UrlSpec

impl Send for VisibleAngleTransform

impl Send for VisiblePieceId

impl Send for WantedTestsOpt

impl Send for WholeServerConfig

impl Send for ZLevel

impl Send for AccessError

impl Send for otter_api_tests::thread::Builder

impl Send for Thread

impl Send for ThreadId

impl Send for SystemTime

impl Send for SystemTimeError

impl Send for AccessFlags

impl Send for Gid

impl Send for otter_api_tests::unistd::Group

impl Send for Pid

impl Send for User

impl Send for SocketAddr

impl Send for SocketCred

impl Send for UnixDatagram

impl Send for UnixListener

impl Send for UCred

impl Send for AddSubRangeDelta

impl Send for Decrement

impl Send for Increment

impl Send for LimbVal

impl Send for Mutable

impl Send for MutateFirst

impl Send for MutateLast

impl Send for Overflow

impl Send for otter_api_tests::zcoord::ParseError

impl Send for RangeBackwards

impl Send for Sealed

impl Send for TotallyUnboundedRange

impl Send for otter_api_tests::imports::anyhow::Error

impl Send for InternalFixed

impl Send for InternalNumeric

impl Send for Parsed

impl Send for otter_api_tests::imports::chrono::Duration

impl Send for FixedOffset

impl Send for IsoWeek

impl Send for Local

impl Send for NaiveDate

impl Send for NaiveDateTime

impl Send for NaiveTime

impl Send for otter_api_tests::imports::chrono::ParseError

impl Send for ParseMonthError

impl Send for ParseWeekdayError

impl Send for Utc

impl Send for otter_api_tests::imports::env_logger::filter::Builder

impl Send for otter_api_tests::imports::env_logger::filter::Filter

impl Send for otter_api_tests::imports::env_logger::fmt::Timestamp

impl Send for otter_api_tests::imports::env_logger::Builder

impl Send for otter_api_tests::imports::env_logger::Logger

impl Send for FsStats

impl Send for GlobError

impl Send for MatchOptions

impl Send for Paths

impl Send for Pattern

impl Send for PatternError

impl Send for Elf32_Chdr

impl Send for Elf32_Ehdr

impl Send for Elf32_Phdr

impl Send for Elf32_Shdr

impl Send for Elf32_Sym

impl Send for Elf64_Chdr

impl Send for Elf64_Ehdr

impl Send for Elf64_Phdr

impl Send for Elf64_Shdr

impl Send for Elf64_Sym

impl Send for __c_anonymous_sockaddr_can_j1939

impl Send for __c_anonymous_sockaddr_can_tp

impl Send for __exit_status

impl Send for __timeval

impl Send for _libc_fpstate

impl Send for _libc_fpxreg

impl Send for _libc_xmmreg

impl Send for af_alg_iv

impl Send for arpd_request

impl Send for arphdr

impl Send for arpreq

impl Send for arpreq_old

impl Send for can_filter

impl Send for can_frame

impl Send for canfd_frame

impl Send for cpu_set_t

impl Send for dirent64

impl Send for dirent

impl Send for dqblk

impl Send for epoll_event

impl Send for fanotify_event_metadata

impl Send for fanotify_response

impl Send for fd_set

impl Send for ff_condition_effect

impl Send for ff_constant_effect

impl Send for ff_effect

impl Send for ff_envelope

impl Send for ff_ramp_effect

impl Send for ff_replay

impl Send for ff_rumble_effect

impl Send for ff_trigger

impl Send for flock64

impl Send for flock

impl Send for fsid_t

impl Send for genlmsghdr

impl Send for in6_addr

impl Send for in6_pktinfo

impl Send for in6_rtmsg

impl Send for in_addr

impl Send for in_pktinfo

impl Send for inotify_event

impl Send for input_absinfo

impl Send for input_event

impl Send for input_id

impl Send for input_keymap_entry

impl Send for input_mask

impl Send for ip_mreq

impl Send for ip_mreq_source

impl Send for ip_mreqn

impl Send for ipc_perm

impl Send for ipv6_mreq

impl Send for itimerspec

impl Send for itimerval

impl Send for linger

impl Send for mallinfo

impl Send for max_align_t

impl Send for mq_attr

impl Send for msginfo

impl Send for msqid_ds

impl Send for nl_mmap_hdr

impl Send for nl_mmap_req

impl Send for nl_pktinfo

impl Send for nlattr

impl Send for nlmsgerr

impl Send for nlmsghdr

impl Send for ntptimeval

impl Send for packet_mreq

impl Send for pollfd

impl Send for posix_spawnattr_t

impl Send for pthread_attr_t

impl Send for pthread_cond_t

impl Send for pthread_condattr_t

impl Send for pthread_mutex_t

impl Send for pthread_mutexattr_t

impl Send for pthread_rwlock_t

impl Send for pthread_rwlockattr_t

impl Send for regmatch_t

impl Send for rlimit64

impl Send for rlimit

impl Send for rusage

impl Send for sched_param

impl Send for sem_t

impl Send for sembuf

impl Send for shmid_ds

impl Send for sigaction

impl Send for siginfo_t

impl Send for sigset_t

impl Send for sock_extended_err

impl Send for sockaddr_alg

impl Send for sockaddr_can

impl Send for sockaddr_ll

impl Send for sockaddr_nl

impl Send for sockaddr_vm

impl Send for stat64

impl Send for statfs64

impl Send for statfs

impl Send for statvfs64

impl Send for statvfs

impl Send for statx

impl Send for statx_timestamp

impl Send for sysinfo

impl Send for termios2

impl Send for termios

impl Send for timespec

impl Send for timeval

impl Send for timex

impl Send for tms

impl Send for ucred

impl Send for uinput_abs_setup

impl Send for uinput_ff_erase

impl Send for uinput_ff_upload

impl Send for uinput_setup

impl Send for uinput_user_dev

impl Send for user_fpregs_struct

impl Send for user_regs_struct

impl Send for utimbuf

impl Send for utmpx

impl Send for utsname

impl Send for ParseLevelError

impl Send for SetLoggerError

impl Send for otter_api_tests::imports::nix::dir::Entry

impl Send for OwningIter

impl Send for AtFlags

impl Send for FallocateFlags

impl Send for otter_api_tests::imports::nix::fcntl::FdFlag

impl Send for OFlag

impl Send for SealFlag

impl Send for SpliceFFlags

impl Send for InterfaceAddress

impl Send for DeleteModuleFlags

impl Send for ModuleInitFlags

impl Send for MntFlags

impl Send for otter_api_tests::imports::nix::mount::MsFlags

impl Send for otter_api_tests::imports::nix::mqueue::FdFlag

impl Send for MQ_OFlag

impl Send for MqAttr

impl Send for InterfaceFlags

impl Send for PollFd

impl Send for PollFlags

impl Send for ForkptyResult

impl Send for OpenptyResult

impl Send for PtyMaster

impl Send for winsize

impl Send for CloneFlags

impl Send for CpuSet

impl Send for EpollCreateFlags

impl Send for EpollEvent

impl Send for EpollFlags

impl Send for EfdFlags

impl Send for AddWatchFlags

impl Send for InitFlags

impl Send for Inotify

impl Send for InotifyEvent

impl Send for WatchDescriptor

impl Send for MemFdCreateFlag

impl Send for MRemapFlags

impl Send for MapFlags

impl Send for MlockAllFlags

impl Send for otter_api_tests::imports::nix::sys::mman::MsFlags

impl Send for ProtFlags

impl Send for Persona

impl Send for Options

impl Send for Dqblk

impl Send for QuotaValidFlags

impl Send for FdSet

impl Send for SaFlags

impl Send for SigAction

impl Send for SignalIterator

impl Send for SfdFlags

impl Send for SigSet

impl Send for SignalFd

impl Send for signalfd_siginfo

impl Send for AcceptConn

impl Send for AlgSetAeadAuthSize

impl Send for BindToDevice

impl Send for Broadcast

impl Send for IpAddMembership

impl Send for IpDropMembership

impl Send for IpMulticastLoop

impl Send for IpMulticastTtl

impl Send for IpTransparent

impl Send for Ipv4PacketInfo

impl Send for Ipv6AddMembership

impl Send for Ipv6DropMembership

impl Send for Ipv6RecvPacketInfo

impl Send for KeepAlive

impl Send for Linger

impl Send for Mark

impl Send for OobInline

impl Send for OriginalDst

impl Send for PassCred

impl Send for PeerCredentials

impl Send for RcvBuf

impl Send for RcvBufForce

impl Send for ReceiveTimeout

impl Send for ReceiveTimestamp

impl Send for ReuseAddr

impl Send for ReusePort

impl Send for SendTimeout

impl Send for SndBuf

impl Send for SndBufForce

impl Send for otter_api_tests::imports::nix::sys::socket::sockopt::SockType

impl Send for SocketError

impl Send for TcpCongestion

impl Send for TcpKeepCount

impl Send for TcpKeepIdle

impl Send for TcpKeepInterval

impl Send for TcpNoDelay

impl Send for UdpGroSegment

impl Send for UdpGsoSegment

impl Send for AlgAddr

impl Send for IpMembershipRequest

impl Send for Ipv4Addr

impl Send for Ipv6Addr

impl Send for Ipv6MembershipRequest

impl Send for LinkAddr

impl Send for MsgFlags

impl Send for NetlinkAddr

impl Send for SockFlag

impl Send for UnixAddr

impl Send for UnixCredentials

impl Send for VsockAddr

impl Send for cmsghdr

impl Send for sockaddr

impl Send for sockaddr_in6

impl Send for sockaddr_in

impl Send for sockaddr_storage

impl Send for sockaddr_un

impl Send for stat

impl Send for Mode

impl Send for SFlag

impl Send for FsType

impl Send for Statfs

impl Send for FsFlags

impl Send for Statvfs

impl Send for SysInfo

impl Send for ControlFlags

impl Send for InputFlags

impl Send for LocalFlags

impl Send for OutputFlags

impl Send for Termios

impl Send for TimeVal

impl Send for TimerFd

impl Send for TimerFlags

impl Send for TimerSetTimeFlags

impl Send for RemoteIoVec

impl Send for UtsName

impl Send for WaitPidFlag

impl Send for otter_api_tests::imports::nix::time::ClockId

impl Send for OnceBool

impl Send for OnceNonZeroUsize

impl Send for FloatIsNan

impl Send for DecodeErr

impl Send for IgnoredAny

impl Send for otter_api_tests::imports::otter_base::imports::serde::de::value::Error

impl Send for GuardSend

impl Send for otter_api_tests::imports::parking_lot::Once

impl Send for RawFairMutex

impl Send for RawMutex

impl Send for RawRwLock

impl Send for RawThreadId

impl Send for WaitTimeoutResult

impl Send for Passwd

impl Send for otter_api_tests::imports::regex::bytes::CaptureLocations

impl Send for otter_api_tests::imports::regex::bytes::Regex

impl Send for otter_api_tests::imports::regex::bytes::RegexBuilder

impl Send for otter_api_tests::imports::regex::bytes::RegexSet

impl Send for otter_api_tests::imports::regex::bytes::RegexSetBuilder

impl Send for otter_api_tests::imports::regex::bytes::SetMatches

impl Send for otter_api_tests::imports::regex::bytes::SetMatchesIntoIter

impl Send for otter_api_tests::imports::regex::CaptureLocations

impl Send for otter_api_tests::imports::regex::RegexBuilder

impl Send for otter_api_tests::imports::regex::RegexSet

impl Send for otter_api_tests::imports::regex::RegexSetBuilder

impl Send for otter_api_tests::imports::regex::SetMatches

impl Send for otter_api_tests::imports::regex::SetMatchesIntoIter

impl Send for DefaultConfig

impl Send for Raw

impl Send for DefaultKey

impl Send for KeyData

impl Send for otter_api_tests::imports::toml::de::Error

impl Send for otter_api_tests::imports::toml::map::IntoIter

impl Send for Datetime

impl Send for DatetimeParseError

impl Send for NonblockingUnixSeqpacketConn

impl Send for NonblockingUnixSeqpacketListener

impl Send for UnixSeqpacketConn

impl Send for UnixSeqpacketListener

impl Send for UnixSocketAddr

impl Send for Backtrace

impl Send for otter_api_tests::imports::failure::Error

impl Send for AllocError

impl Send for Layout

impl Send for LayoutError

impl Send for TypeId

impl Send for CpuidResult

impl Send for __m128

impl Send for __m128bh

impl Send for __m128d

impl Send for __m128i

impl Send for __m256

impl Send for __m256bh

impl Send for __m256d

impl Send for __m256i

impl Send for __m512

impl Send for __m512bh

impl Send for __m512d

impl Send for __m512i

impl Send for TryFromSliceError

impl Send for otter_api_tests::imports::failure::_core::ascii::EscapeDefault

impl Send for BorrowError

impl Send for BorrowMutError

impl Send for CharTryFromError

impl Send for DecodeUtf16Error

impl Send for otter_api_tests::imports::failure::_core::char::EscapeDebug

impl Send for otter_api_tests::imports::failure::_core::char::EscapeDefault

impl Send for otter_api_tests::imports::failure::_core::char::EscapeUnicode

impl Send for ParseCharError

impl Send for ToLowercase

impl Send for ToUppercase

impl Send for SipHasher

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 ParseFloatError

impl Send for ParseIntError

impl Send for RangeFull

impl Send for NoneError

impl Send for Utf8Lossy

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 RawWakerVTable

impl Send for PhantomPinned

impl Send for __c_anonymous_sockaddr_can_can_addr

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

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

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

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

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

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

impl<'a> !Send for otter_api_tests::shapelib::Formatter<'a>

impl<'a> !Send for otter_api_tests::imports::anyhow::Chain<'a>

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

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

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

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

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

impl<'a> !Send for otter_api_tests::imports::toml::Serializer<'a>

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

impl<'a> Send for otter_api_tests::serde_json::map::Entry<'a>

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

impl<'a> Send for otter_api_tests::imports::chrono::format::Item<'a>

impl<'a> Send for FcntlArg<'a>

impl<'a> Send for ControlMessage<'a>

impl<'a> Send for Unexpected<'a>

impl<'a> Send for otter_api_tests::imports::toml::map::Entry<'a>

impl<'a> Send for AddrName<'a>

impl<'a> Send for SplitPaths<'a>

impl<'a> Send for SliceRead<'a>

impl<'a> Send for StrRead<'a>

impl<'a> Send for otter_api_tests::serde_json::map::Iter<'a>

impl<'a> Send for otter_api_tests::serde_json::map::IterMut<'a>

impl<'a> Send for otter_api_tests::serde_json::map::Keys<'a>

impl<'a> Send for otter_api_tests::serde_json::map::OccupiedEntry<'a>

impl<'a> Send for otter_api_tests::serde_json::map::VacantEntry<'a>

impl<'a> Send for otter_api_tests::serde_json::map::Values<'a>

impl<'a> Send for otter_api_tests::serde_json::map::ValuesMut<'a>

impl<'a> Send for PrettyFormatter<'a>

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

impl<'a> Send for otter_api_tests::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 otter_api_tests::str::EscapeDebug<'a>

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

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

impl<'a> Send for otter_api_tests::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 ApiPieceOpArgs<'a>

impl<'a> Send for 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 StrftimeItems<'a>

impl<'a> Send for Env<'a>

impl<'a> Send for otter_api_tests::imports::log::Metadata<'a>

impl<'a> Send for MetadataBuilder<'a>

impl<'a> Send for Fds<'a>

impl<'a> Send for otter_api_tests::imports::regex::bytes::SetMatchesIter<'a>

impl<'a> Send for otter_api_tests::imports::regex::SetMatchesIter<'a>

impl<'a> Send for RawRef<'a>

impl<'a> Send for otter_api_tests::imports::toml::map::Iter<'a>

impl<'a> Send for otter_api_tests::imports::toml::map::IterMut<'a>

impl<'a> Send for otter_api_tests::imports::toml::map::Keys<'a>

impl<'a> Send for otter_api_tests::imports::toml::map::OccupiedEntry<'a>

impl<'a> Send for otter_api_tests::imports::toml::map::VacantEntry<'a>

impl<'a> Send for otter_api_tests::imports::toml::map::Values<'a>

impl<'a> Send for otter_api_tests::imports::toml::Deserializer<'a>

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

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

impl<'a> Send for Utf8LossyChunk<'a>

impl<'a> Send for Utf8LossyChunksIter<'a>

impl<'a> Send for otter_api_tests::imports::failure::_core::task::Context<'a>

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, 'f> !Send for VaList<'a, 'f>

impl<'a, A> Send for otter_api_tests::imports::failure::_core::option::Iter<'a, A> where
    A: Sync

impl<'a, A> Send for otter_api_tests::imports::failure::_core::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, E> Send for BytesDeserializer<'a, E> where
    E: Send

impl<'a, E> Send for CowStrDeserializer<'a, E> where
    E: Send

impl<'a, E> Send for otter_api_tests::imports::otter_base::imports::serde::de::value::StrDeserializer<'a, E> where
    E: Send

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

impl<'a, I> !Send for Chunk<'a, I>

impl<'a, I> !Send for otter_api_tests::imports::otter_base::imports::itertools::Chunks<'a, I>

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

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

impl<'a, I, C> Send for SendMmsgData<'a, I, C> where
    C: Send,
    I: Send + Sync

impl<'a, I, E> Send for ProcessResults<'a, I, E> where
    E: Send,
    I: Send

impl<'a, I, F> Send for FormatWith<'a, I, F> where
    F: Send,
    I: Send

impl<'a, I, F> Send for PeekingTakeWhile<'a, I, F> where
    F: Send,
    I: Send

impl<'a, I, F> Send for TakeWhileRef<'a, I, F> where
    F: Send,
    I: Send

impl<'a, K, I, F> !Send for otter_api_tests::imports::otter_base::imports::itertools::Group<'a, K, I, F>

impl<'a, K, I, F> !Send for Groups<'a, K, I, F>

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

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

impl<'a, K, V> Send for otter_api_tests::imports::slotmap::secondary::Entry<'a, K, V> where
    V: Send

impl<'a, K, V> Send for otter_api_tests::imports::slotmap::sparse_secondary::Entry<'a, K, V> where
    V: Send

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

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

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

impl<'a, K, V> Send for otter_api_tests::btree_map::OccupiedEntry<'a, K, V> where
    K: Send,
    V: Send

impl<'a, K, V> Send for otter_api_tests::btree_map::OccupiedError<'a, K, V> where
    K: Send,
    V: Send

impl<'a, K, V> Send for otter_api_tests::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 otter_api_tests::btree_map::VacantEntry<'a, K, V> where
    K: Send,
    V: Send

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

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

impl<'a, K, V> Send for otter_api_tests::hash_map::Drain<'a, K, V> where
    K: Send,
    V: Send

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

impl<'a, K, V> Send for otter_api_tests::hash_map::IterMut<'a, K, V> where
    K: Send,
    V: Send

impl<'a, K, V> Send for otter_api_tests::hash_map::Keys<'a, K, V> where
    K: Sync,
    V: Sync

impl<'a, K, V> Send for otter_api_tests::hash_map::OccupiedEntry<'a, K, V> where
    K: Send,
    V: Send

impl<'a, K, V> Send for otter_api_tests::hash_map::OccupiedError<'a, K, V> where
    K: Send,
    V: Send

impl<'a, K, V> Send for otter_api_tests::hash_map::VacantEntry<'a, K, V> where
    K: Send,
    V: Send

impl<'a, K, V> Send for otter_api_tests::hash_map::Values<'a, K, V> where
    K: Sync,
    V: Sync

impl<'a, K, V> Send for otter_api_tests::hash_map::ValuesMut<'a, K, V> where
    K: Send,
    V: Send

impl<'a, K, V> Send for otter_api_tests::imports::slotmap::basic::Drain<'a, K, V> where
    V: Send

impl<'a, K, V> Send for otter_api_tests::imports::slotmap::basic::Iter<'a, K, V> where
    V: Sync

impl<'a, K, V> Send for otter_api_tests::imports::slotmap::basic::IterMut<'a, K, V> where
    V: Send

impl<'a, K, V> Send for otter_api_tests::imports::slotmap::basic::Keys<'a, K, V> where
    V: Sync

impl<'a, K, V> Send for otter_api_tests::imports::slotmap::basic::Values<'a, K, V> where
    V: Sync

impl<'a, K, V> Send for otter_api_tests::imports::slotmap::basic::ValuesMut<'a, K, V> where
    V: Send

impl<'a, K, V> Send for otter_api_tests::imports::slotmap::dense::Drain<'a, K, V> where
    K: Send,
    V: Send

impl<'a, K, V> Send for otter_api_tests::imports::slotmap::dense::Iter<'a, K, V> where
    K: Sync,
    V: Sync

impl<'a, K, V> Send for otter_api_tests::imports::slotmap::dense::IterMut<'a, K, V> where
    K: Sync,
    V: Send

impl<'a, K, V> Send for otter_api_tests::imports::slotmap::dense::Keys<'a, K, V> where
    K: Sync,
    V: Sync

impl<'a, K, V> Send for otter_api_tests::imports::slotmap::dense::Values<'a, K, V> where
    K: Sync,
    V: Sync

impl<'a, K, V> Send for otter_api_tests::imports::slotmap::dense::ValuesMut<'a, K, V> where
    K: Sync,
    V: Send

impl<'a, K, V> Send for otter_api_tests::imports::slotmap::hop::Drain<'a, K, V> where
    V: Send

impl<'a, K, V> Send for otter_api_tests::imports::slotmap::hop::Iter<'a, K, V> where
    V: Sync

impl<'a, K, V> Send for otter_api_tests::imports::slotmap::hop::IterMut<'a, K, V> where
    V: Send

impl<'a, K, V> Send for otter_api_tests::imports::slotmap::hop::Keys<'a, K, V> where
    V: Sync

impl<'a, K, V> Send for otter_api_tests::imports::slotmap::hop::Values<'a, K, V> where
    V: Sync

impl<'a, K, V> Send for otter_api_tests::imports::slotmap::hop::ValuesMut<'a, K, V> where
    V: Send

impl<'a, K, V> Send for otter_api_tests::imports::slotmap::secondary::Drain<'a, K, V> where
    V: Send

impl<'a, K, V> Send for otter_api_tests::imports::slotmap::secondary::Iter<'a, K, V> where
    V: Sync

impl<'a, K, V> Send for otter_api_tests::imports::slotmap::secondary::IterMut<'a, K, V> where
    V: Send

impl<'a, K, V> Send for otter_api_tests::imports::slotmap::secondary::Keys<'a, K, V> where
    V: Sync

impl<'a, K, V> Send for otter_api_tests::imports::slotmap::secondary::OccupiedEntry<'a, K, V> where
    V: Send

impl<'a, K, V> Send for otter_api_tests::imports::slotmap::secondary::VacantEntry<'a, K, V> where
    V: Send

impl<'a, K, V> Send for otter_api_tests::imports::slotmap::secondary::Values<'a, K, V> where
    V: Sync

impl<'a, K, V> Send for otter_api_tests::imports::slotmap::secondary::ValuesMut<'a, K, V> where
    V: Send

impl<'a, K, V> Send for otter_api_tests::imports::slotmap::sparse_secondary::Drain<'a, K, V> where
    V: Send

impl<'a, K, V> Send for otter_api_tests::imports::slotmap::sparse_secondary::Iter<'a, K, V> where
    V: Sync

impl<'a, K, V> Send for otter_api_tests::imports::slotmap::sparse_secondary::IterMut<'a, K, V> where
    V: Send

impl<'a, K, V> Send for otter_api_tests::imports::slotmap::sparse_secondary::Keys<'a, K, V> where
    V: Sync

impl<'a, K, V> Send for otter_api_tests::imports::slotmap::sparse_secondary::OccupiedEntry<'a, K, V> where
    V: Send

impl<'a, K, V> Send for otter_api_tests::imports::slotmap::sparse_secondary::VacantEntry<'a, K, V> where
    V: Send

impl<'a, K, V> Send for otter_api_tests::imports::slotmap::sparse_secondary::Values<'a, K, V> where
    V: Sync

impl<'a, K, V> Send for otter_api_tests::imports::slotmap::sparse_secondary::ValuesMut<'a, K, V> where
    V: Send

impl<'a, K, V, F> Send for otter_api_tests::btree_map::DrainFilter<'a, K, V, F> where
    F: Send,
    K: Send,
    V: Send

impl<'a, K, V, F> Send for otter_api_tests::hash_map::DrainFilter<'a, K, V, F> where
    F: Send,
    K: Send,
    V: Send

impl<'a, K, V, S> Send for RawEntryMut<'a, K, V, S> where
    K: Send,
    S: 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 RawOccupiedEntryMut<'a, K, V, S> where
    K: 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 otter_api_tests::str::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 otter_api_tests::str::RSplit<'a, P> where
    <P as Pattern<'a>>::Searcher: Send

impl<'a, P> Send for otter_api_tests::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 otter_api_tests::str::Split<'a, P> where
    <P as Pattern<'a>>::Searcher: Send

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

impl<'a, P> Send for otter_api_tests::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, R, G, T> !Send for MappedReentrantMutexGuard<'a, R, G, T>

impl<'a, R, G, T> !Send for ReentrantMutexGuard<'a, R, G, T>

impl<'a, R, T: ?Sized> Send for otter_api_tests::imports::parking_lot::lock_api::MutexGuard<'a, R, T> where
    R: Sync,
    T: Send,
    <R as RawMutex>::GuardMarker: Send

impl<'a, R, T: ?Sized> Send for otter_api_tests::imports::parking_lot::lock_api::RwLockReadGuard<'a, R, T> where
    R: Sync,
    T: Send + Sync,
    <R as RawRwLock>::GuardMarker: Send

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

impl<'a, R, T: ?Sized> Send for otter_api_tests::imports::parking_lot::lock_api::RwLockWriteGuard<'a, R, T> where
    R: Sync,
    T: Send + Sync,
    <R as RawRwLock>::GuardMarker: Send

impl<'a, R: ?Sized> Send for otter_api_tests::imports::regex::bytes::ReplacerRef<'a, R> where
    R: Send

impl<'a, R: ?Sized> Send for otter_api_tests::imports::regex::ReplacerRef<'a, R> where
    R: Send

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

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

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

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

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

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

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

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

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

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

impl<'a, T> Send for otter_api_tests::imports::failure::_core::result::Iter<'a, T> where
    T: Sync

impl<'a, T> Send for otter_api_tests::imports::failure::_core::result::IterMut<'a, T> where
    T: Send

impl<'a, T> Send for otter_api_tests::imports::failure::_core::slice::Chunks<'a, T> where
    T: Sync

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

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

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

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 RChunksExactMut<'a, T> where
    T: Send

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

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

impl<'a, T, F> Send for otter_api_tests::btree_set::DrainFilter<'a, T, F> where
    F: Send,
    T: Send

impl<'a, T, P> Send for otter_api_tests::imports::failure::_core::slice::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 otter_api_tests::imports::failure::_core::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 otter_api_tests::imports::failure::_core::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 otter_api_tests::imports::failure::_core::slice::Split<'a, T, P> where
    P: Send,
    T: Sync

impl<'a, T, P> Send for otter_api_tests::imports::failure::_core::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 otter_api_tests::imports::failure::_core::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, const N: usize> !Send for ArrayWindows<'a, T, N>

impl<'a, T, const N: usize> Send for 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> Send for ExtFieldSerializer<'a, W> where
    W: Send

impl<'a, W> Send for ExtSerializer<'a, W> where
    W: Send

impl<'a, W, C> Send for Compound<'a, W, C> where
    C: Send,
    W: Send

impl<'a, W, C> Send for MaybeUnknownLengthCompound<'a, W, C> where
    C: Send,
    W: Send

impl<'b, 'c, T: ?Sized> Send for Reference<'b, 'c, T> where
    T: Sync

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

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

impl<'c, 't> Send for otter_api_tests::imports::regex::bytes::SubCaptureMatches<'c, 't>

impl<'c, 't> Send for otter_api_tests::imports::regex::SubCaptureMatches<'c, 't>

impl<'d> Send for otter_api_tests::imports::nix::dir::Iter<'d>

impl<'de> Send for TomlDe<'de>

impl<'de, E> Send for BorrowedBytesDeserializer<'de, E> where
    E: Send

impl<'de, E> Send for otter_api_tests::imports::otter_base::imports::serde::de::value::BorrowedStrDeserializer<'de, E> where
    E: Send

impl<'de, I, E> Send for MapDeserializer<'de, I, E> where
    E: Send,
    I: Send,
    <<I as Iterator>::Item as Pair>::Second: Send

impl<'de, R, T> Send for StreamDeserializer<'de, R, T> where
    R: Send,
    T: Send

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

impl<'f> Send for Causes<'f>

impl<'g> !Send for InstanceGuard<'g>

impl<'g> Send for UniqueGenGen<'g>

impl<'i, P> Send for EffectiveACL<'i, P>

impl<'r> Send for PrepareUpdatesBuffer<'r>

impl<'r> Send for otter_api_tests::imports::regex::bytes::CaptureNames<'r>

impl<'r> Send for otter_api_tests::imports::regex::CaptureNames<'r>

impl<'r, 't> Send for otter_api_tests::imports::regex::bytes::CaptureMatches<'r, 't>

impl<'r, 't> Send for otter_api_tests::imports::regex::bytes::Matches<'r, 't>

impl<'r, 't> Send for otter_api_tests::imports::regex::bytes::Split<'r, 't>

impl<'r, 't> Send for otter_api_tests::imports::regex::bytes::SplitN<'r, 't>

impl<'r, 't> Send for otter_api_tests::imports::regex::CaptureMatches<'r, 't>

impl<'r, 't> Send for otter_api_tests::imports::regex::Matches<'r, 't>

impl<'r, 't> Send for otter_api_tests::imports::regex::Split<'r, 't>

impl<'r, 't> Send for otter_api_tests::imports::regex::SplitN<'r, 't>

impl<'t> Send for otter_api_tests::imports::regex::bytes::Captures<'t>

impl<'t> Send for otter_api_tests::imports::regex::bytes::Match<'t>

impl<'t> Send for otter_api_tests::imports::regex::bytes::NoExpand<'t>

impl<'t> Send for otter_api_tests::imports::regex::Captures<'t>

impl<'t> Send for otter_api_tests::imports::regex::Match<'t>

impl<'t> Send for otter_api_tests::imports::regex::NoExpand<'t>

impl<'u> Send for TransmitUpdate<'u>

impl<'v, T, I> Send for otter_api_tests::imports::vecdeque_stableix::Iter<'v, T, I> where
    I: Send + Sync,
    T: Sync

impl<A> !Send for Authorisation<A>

impl<A> Send for otter_api_tests::iter::Repeat<A> where
    A: Send

impl<A> Send for ArrayVec<A> where
    A: Send,
    <A as Array>::Index: Send

impl<A> Send for ArrayString<A> where
    A: Send,
    <A as Array>::Index: Send

impl<A> Send for otter_api_tests::imports::otter_base::imports::arrayvec::IntoIter<A> where
    A: Send,
    <A as Array>::Index: Send

impl<A> Send for RepeatN<A> where
    A: Send

impl<A> Send for MapAccessDeserializer<A> where
    A: Send

impl<A> Send for SeqAccessDeserializer<A> where
    A: Send

impl<A> Send for otter_api_tests::imports::failure::_core::option::IntoIter<A> where
    A: Send

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

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

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

impl<ASO, MR> Send for IteratorCore<ASO, MR> where
    ASO: Send,
    MR: Send

impl<B> Send for otter_api_tests::io::Lines<B> where
    B: Send

impl<B> Send for otter_api_tests::io::Split<B> where
    B: Send

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

impl<B, X> Send for ExtendedSubst<B, X> where
    B: Send,
    X: Send

impl<C> Send for BinaryConfig<C> where
    C: Send

impl<C> Send for HumanReadableConfig<C> where
    C: Send

impl<C> Send for StructMapConfig<C> where
    C: Send

impl<C> Send for StructTupleConfig<C> where
    C: Send

impl<C> Send for VariantIntegerConfig<C> where
    C: Send

impl<C> Send for VariantStringConfig<C> where
    C: Send

impl<D> Send for OccultationKindGeneral<D> where
    D: Send

impl<D> Send for otter_api_tests::imports::failure::Context<D>

impl<Desc, Outl> Send for GenericSimpleShape<Desc, Outl> where
    Desc: Send,
    Outl: Send

impl<E> Send for Loop<E> where
    E: Send

impl<E> Send for ParseNotNanError<E> where
    E: Send

impl<E> Send for BoolDeserializer<E> where
    E: Send

impl<E> Send for CharDeserializer<E> where
    E: Send

impl<E> Send for F32Deserializer<E> where
    E: Send

impl<E> Send for F64Deserializer<E> where
    E: Send

impl<E> Send for I8Deserializer<E> where
    E: Send

impl<E> Send for I16Deserializer<E> where
    E: Send

impl<E> Send for I32Deserializer<E> where
    E: Send

impl<E> Send for I64Deserializer<E> where
    E: Send

impl<E> Send for I128Deserializer<E> where
    E: Send

impl<E> Send for IsizeDeserializer<E> where
    E: Send

impl<E> Send for StringDeserializer<E> where
    E: Send

impl<E> Send for U8Deserializer<E> where
    E: Send

impl<E> Send for U16Deserializer<E> where
    E: Send

impl<E> Send for U32Deserializer<E> where
    E: Send

impl<E> Send for U64Deserializer<E> where
    E: Send

impl<E> Send for U128Deserializer<E> where
    E: Send

impl<E> Send for UnitDeserializer<E> where
    E: Send

impl<E> Send for UsizeDeserializer<E> where
    E: Send

impl<E> Send for Compat<E> where
    E: 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<F> Send for RepeatCall<F> where
    F: Send

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

impl<H> Send for BuildHasherDefault<H> where
    H: Send

impl<I> !Send for RcIter<I>

impl<I> !Send for Tee<I>

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 otter_api_tests::iter::Take<I> where
    I: Send

impl<I> Send for DelayedFormat<I> where
    I: Send

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

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

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

impl<I> Send for GroupingMap<I> where
    I: Send

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

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

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

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

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

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

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

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

impl<I> Send for Step<I> where
    I: Send

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

impl<I> Send for WhileSome<I> where
    I: Send

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

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

impl<I, E> Send for SeqDeserializer<I, E> where
    E: Send,
    I: Send

impl<I, ElemF> Send for otter_api_tests::imports::otter_base::imports::itertools::IntersperseWith<I, ElemF> where
    ElemF: Send,
    I: Send,
    <I as Iterator>::Item: 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 otter_api_tests::iter::Map<I, F> where
    F: Send,
    I: Send

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

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

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

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

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

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

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

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

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

impl<I, J> Send for ConsTuples<I, J> where
    I: Send

impl<I, J> Send for Interleave<I, J> where
    I: Send,
    J: Send

impl<I, J> Send for InterleaveShortest<I, J> where
    I: Send,
    J: Send

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

impl<I, J> Send for ZipEq<I, J> where
    I: Send,
    J: Send

impl<I, J, F> Send for MergeBy<I, J, F> where
    F: Send,
    I: Send,
    J: Send,
    <I as Iterator>::Item: Send

impl<I, J, F> Send for MergeJoinBy<I, J, F> where
    F: Send,
    I: Send,
    J: Send,
    <I as Iterator>::Item: Send,
    <J as Iterator>::Item: Send

impl<I, P> Send for otter_api_tests::iter::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, T> Send for CircularTupleWindows<I, T> where
    I: Send,
    T: Send

impl<I, T> Send for TupleCombinations<I, T> where
    I: Send,
    T: Send,
    <T as HasCombination<I>>::Combination: Send

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

impl<I, T> Send for Tuples<I, T> where
    I: Send,
    <T as TupleCollect>::Buffer: Send

impl<I, T: ?Sized> Send for IndexSlice<I, T> where
    T: Send

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

impl<I, V, F> Send for UniqueBy<I, V, F> where
    F: Send,
    I: Send,
    V: Send

impl<Id> Send for InstanceAccessDetails<Id> where
    Id: Send

impl<Id> Send for TokenRegistry<Id> where
    Id: Send

impl<Idx> Send for otter_api_tests::imports::failure::_core::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, I, F> Send for otter_api_tests::imports::otter_base::imports::itertools::GroupBy<K, I, F> where
    F: Send,
    I: Send,
    K: Send,
    <I as Iterator>::Item: Send

impl<K, V> Send for otter_api_tests::btree_map::IntoIter<K, V> where
    K: Send,
    V: Send

impl<K, V> Send for otter_api_tests::btree_map::IntoKeys<K, V> where
    K: Send,
    V: Send

impl<K, V> Send for otter_api_tests::btree_map::IntoValues<K, V> where
    K: Send,
    V: Send

impl<K, V> Send for otter_api_tests::hash_map::IntoIter<K, V> where
    K: Send,
    V: Send

impl<K, V> Send for otter_api_tests::hash_map::IntoKeys<K, V> where
    K: Send,
    V: Send

impl<K, V> Send for otter_api_tests::hash_map::IntoValues<K, V> where
    K: Send,
    V: Send

impl<K, V> Send for otter_api_tests::serde_json::Map<K, V> where
    K: Send,
    V: Send

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

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

impl<K, V> Send for EnumMap<K, V> where
    <K as Enum<V>>::Array: Send

impl<K, V> Send for otter_api_tests::imports::slotmap::basic::IntoIter<K, V> where
    V: Send

impl<K, V> Send for otter_api_tests::imports::slotmap::dense::IntoIter<K, V> where
    K: Send,
    V: Send

impl<K, V> Send for otter_api_tests::imports::slotmap::hop::IntoIter<K, V> where
    V: Send

impl<K, V> Send for otter_api_tests::imports::slotmap::secondary::IntoIter<K, V> where
    V: Send

impl<K, V> Send for otter_api_tests::imports::slotmap::sparse_secondary::IntoIter<K, V> where
    V: Send

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

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

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

impl<K, V> Send for otter_api_tests::imports::toml::value::Map<K, V> where
    K: Send,
    V: Send

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

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

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

impl<NS, ZL> Send for PieceUpdateOp<NS, ZL> where
    NS: Send,
    ZL: Send

impl<Ok, Error> Send for Impossible<Ok, Error> where
    Error: Send,
    Ok: Send

impl<P> Send for LoadedAcl<P>

impl<P> Send for PermSet<P>

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

impl<P, Z> Send for PriOccultedGeneral<P, Z> where
    P: Send,
    Z: Send

impl<POEPU> Send for ErrorSignaledViaUpdate<POEPU> where
    POEPU: Send

impl<Perm> Send for Acl<Perm> where
    Perm: Send

impl<Perm> Send for AclEntry<Perm> where
    Perm: Send

impl<R> Send for otter_api_tests::io::Bytes<R> where
    R: Send

impl<R> Send for IoRead<R> where
    R: Send

impl<R> Send for otter_api_tests::serde_json::Deserializer<R> where
    R: Send

impl<R> Send for BufReader<R> where
    R: Send

impl<R> Send for ReadReader<R> where
    R: Send

impl<R, C> Send for otter_api_tests::imports::rmp_serde::Deserializer<R, C> where
    C: Send,
    R: Send

impl<S: ?Sized, T: ?Sized> Send for ConcreteDynCastConfig<S, T> where
    S: Send,
    T: Send

impl<St, F> Send for Iterate<St, F> where
    F: Send,
    St: Send

impl<St, F> Send for Unfold<St, F> where
    F: Send,
    St: Send

impl<T> !Send for IoVec<T>

impl<T> Send for RegionC<T> where
    T: Send

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

impl<T> Send for LocalResult<T> where
    T: Send

impl<T> Send for FoldWhile<T> where
    T: Send

impl<T> Send for MinMaxResult<T> where
    T: Send

impl<T> Send for Position<T> where
    T: Send

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

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

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

impl<T> Send for otter_api_tests::btree_set::IntoIter<T> where
    T: Send

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

impl<T> Send for otter_api_tests::io::Cursor<T> where
    T: Send

impl<T> Send for otter_api_tests::io::Take<T> where
    T: Send

impl<T> Send for otter_api_tests::iter::Once<T> where
    T: Send

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

impl<T> Send for otter_api_tests::mpsc::IntoIter<T> where
    T: Send

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

impl<T> Send for Discriminant<T>

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

impl<T> Send for DebugReader<T> where
    T: Send

impl<T> Send for OrderedFloat<T> where
    T: Send

impl<T> Send for PosC<T> where
    T: Send

impl<T> Send for RectC<T> where
    T: Send

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

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

impl<T> Send for IsHtmlFormatted<T> where
    T: Send

impl<T> Send for JsonString<T> where
    T: Send

impl<T> Send for OldNew<T> where
    T: Send

impl<T> Send for LocalKey<T>

impl<T> Send for otter_api_tests::thread::__FastLocalKeyInner<T> where
    T: Send

impl<T> Send for otter_api_tests::thread::__OsLocalKeyInner<T> where
    T: Send

impl<T> Send for otter_api_tests::imports::lazy_init::Lazy<T> where
    T: Send

impl<T> Send for AlgSetKey<T> where
    T: Send

impl<T> Send for OnceBox<T> where
    T: Send

impl<T> Send for otter_api_tests::imports::once_cell::sync::OnceCell<T> where
    T: Send

impl<T> Send for otter_api_tests::imports::once_cell::unsync::OnceCell<T> where
    T: Send

impl<T> Send for NotNan<T> where
    T: Send

impl<T> Send for CapacityError<T> where
    T: Send

impl<T> Send for TupleBuffer<T> where
    <T as TupleCollect>::Buffer: Send

impl<T> Send for otter_api_tests::imports::otter_base::imports::itertools::Zip<T> where
    T: Send

impl<T> Send for Spanned<T> where
    T: Send

impl<T> Send for SyncFailure<T> where
    T: Send

impl<T> Send for Pending<T> where
    T: Send

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

impl<T> Send for otter_api_tests::imports::failure::_core::lazy::OnceCell<T> where
    T: Send

impl<T> Send for otter_api_tests::imports::failure::_core::result::IntoIter<T> where
    T: Send

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

impl<T, A> Send for Unauthorised<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 Successors<T, F> where
    F: Send,
    T: Send

impl<T, F> Send for otter_api_tests::imports::once_cell::sync::Lazy<T, F> where
    F: Send,
    T: Send

impl<T, F> Send for otter_api_tests::imports::once_cell::unsync::Lazy<T, F> where
    F: Send,
    T: Send

impl<T, F> Send for otter_api_tests::imports::failure::_core::lazy::Lazy<T, F> where
    F: Send,
    T: Send

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

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

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

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

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

impl<T, const N: usize> Send for otter_api_tests::imports::failure::_core::array::IntoIter<T, N> where
    T: Send

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

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

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

impl<U> Send for PreparedPieceUpdateGeneral<U> where
    U: Send

impl<U, F> Send for Thunk<U, F> where
    F: Send,
    U: Send

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

impl<W> Send for LineWriter<W> where
    W: Send

impl<W> Send for BufWriter<W> where
    W: Send

impl<W, C> Send for otter_api_tests::imports::rmp_serde::Serializer<W, C> where
    C: Send,
    W: Send

impl<W, F> Send for otter_api_tests::serde_json::Serializer<W, F> where
    F: Send,
    W: Send

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

Loading content...