Trait UnwindSafe

1.9.0 · Source
pub auto trait UnwindSafe { }
Expand description

A marker trait which represents “panic safe” types in Rust.

This trait is implemented by default for many types and behaves similarly in terms of inference of implementation to the Send and Sync traits. The purpose of this trait is to encode what types are safe to cross a catch_unwind boundary with no fear of unwind safety.

§What is unwind safety?

In Rust a function can “return” early if it either panics or calls a function which transitively panics. This sort of control flow is not always anticipated, and has the possibility of causing subtle bugs through a combination of two critical components:

  1. A data structure is in a temporarily invalid state when the thread panics.
  2. This broken invariant is then later observed.

Typically in Rust, it is difficult to perform step (2) because catching a panic involves either spawning a thread (which in turn makes it difficult to later witness broken invariants) or using the catch_unwind function in this module. Additionally, even if an invariant is witnessed, it typically isn’t a problem in Rust because there are no uninitialized values (like in C or C++).

It is possible, however, for logical invariants to be broken in Rust, which can end up causing behavioral bugs. Another key aspect of unwind safety in Rust is that, in the absence of unsafe code, a panic cannot lead to memory unsafety.

That was a bit of a whirlwind tour of unwind safety, but for more information about unwind safety and how it applies to Rust, see an associated RFC.

§What is UnwindSafe?

Now that we’ve got an idea of what unwind safety is in Rust, it’s also important to understand what this trait represents. As mentioned above, one way to witness broken invariants is through the catch_unwind function in this module as it allows catching a panic and then re-using the environment of the closure.

Simply put, a type T implements UnwindSafe if it cannot easily allow witnessing a broken invariant through the use of catch_unwind (catching a panic). This trait is an auto trait, so it is automatically implemented for many types, and it is also structurally composed (e.g., a struct is unwind safe if all of its components are unwind safe).

Note, however, that this is not an unsafe trait, so there is not a succinct contract that this trait is providing. Instead it is intended as more of a “speed bump” to alert users of catch_unwind that broken invariants may be witnessed and may need to be accounted for.

§Who implements UnwindSafe?

Types such as &mut T and &RefCell<T> are examples which are not unwind safe. The general idea is that any mutable state which can be shared across catch_unwind is not unwind safe by default. This is because it is very easy to witness a broken invariant outside of catch_unwind as the data is simply accessed as usual.

Types like &Mutex<T>, however, are unwind safe because they implement poisoning by default. They still allow witnessing a broken invariant, but they already provide their own “speed bumps” to do so.

§When should UnwindSafe be used?

It is not intended that most types or functions need to worry about this trait. It is only used as a bound on the catch_unwind function and as mentioned above, the lack of unsafe means it is mostly an advisory. The AssertUnwindSafe wrapper struct can be used to force this trait to be implemented for any closed over variables passed to catch_unwind.

Implementors§

Source§

impl UnwindSafe for CancellationToken

Source§

impl UnwindSafe for rustmax::prelude::AnyError

1.9.0 · Source§

impl UnwindSafe for rustmax::std::io::Stderr

1.9.0 · Source§

impl UnwindSafe for StderrLock<'_>

1.9.0 · Source§

impl UnwindSafe for rustmax::std::io::Stdout

1.9.0 · Source§

impl UnwindSafe for StdoutLock<'_>

1.9.0 · Source§

impl UnwindSafe for Condvar

1.59.0 · Source§

impl UnwindSafe for rustmax::std::sync::Once

Source§

impl UnwindSafe for rustmax::tokio::runtime::Handle

Source§

impl UnwindSafe for Runtime

Source§

impl UnwindSafe for Notify

Source§

impl UnwindSafe for rustmax::tokio::task::AbortHandle

Source§

impl UnwindSafe for Shell

Source§

impl<'a> UnwindSafe for ParseBuffer<'a>

1.64.0 · Source§

impl<K, V, A> UnwindSafe for BTreeMap<K, V, A>

Source§

impl<K, V, S> UnwindSafe for AHashMap<K, V, S>
where K: UnwindSafe, V: UnwindSafe,

1.36.0 · Source§

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

1.9.0 · Source§

impl<T> !UnwindSafe for &mut T
where T: ?Sized,

1.9.0 · Source§

impl<T> UnwindSafe for *const T
where T: RefUnwindSafe + ?Sized,

1.9.0 · Source§

impl<T> UnwindSafe for *mut T
where T: RefUnwindSafe + ?Sized,

1.9.0 · Source§

impl<T> UnwindSafe for &T
where T: RefUnwindSafe + ?Sized,

Source§

impl<T> UnwindSafe for crossbeam_channel::channel::Receiver<T>

Source§

impl<T> UnwindSafe for crossbeam_channel::channel::Sender<T>

Source§

impl<T> UnwindSafe for crossbeam_utils::atomic::atomic_cell::AtomicCell<T>

Source§

impl<T> UnwindSafe for crossbeam_utils::sync::sharded_lock::ShardedLock<T>
where T: ?Sized,

Source§

impl<T> UnwindSafe for once_cell::unsync::OnceCell<T>
where T: UnwindSafe,

Source§

impl<T> UnwindSafe for CachedThreadLocal<T>
where T: Send + UnwindSafe,

Source§

impl<T> UnwindSafe for ThreadLocal<T>
where T: Send + UnwindSafe,

1.28.0 · Source§

impl<T> UnwindSafe for NonZero<T>

1.9.0 · Source§

impl<T> UnwindSafe for AssertUnwindSafe<T>

1.25.0 · Source§

impl<T> UnwindSafe for NonNull<T>
where T: RefUnwindSafe + ?Sized,

Source§

impl<T> UnwindSafe for rustmax::crossbeam::atomic::AtomicCell<T>

Source§

impl<T> UnwindSafe for rustmax::crossbeam::channel::Receiver<T>

Source§

impl<T> UnwindSafe for rustmax::crossbeam::channel::Sender<T>

Source§

impl<T> UnwindSafe for ArrayQueue<T>

Source§

impl<T> UnwindSafe for SegQueue<T>

Source§

impl<T> UnwindSafe for rustmax::crossbeam::sync::ShardedLock<T>
where T: ?Sized,

Source§

impl<T> UnwindSafe for rustmax::std::sync::mpmc::Receiver<T>

Source§

impl<T> UnwindSafe for rustmax::std::sync::mpmc::Sender<T>

1.9.0 · Source§

impl<T> UnwindSafe for rustmax::std::sync::Mutex<T>
where T: ?Sized,

1.70.0 · Source§

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

Source§

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

1.9.0 · Source§

impl<T> UnwindSafe for rustmax::std::sync::RwLock<T>
where T: ?Sized,

Source§

impl<T> UnwindSafe for rustmax::tokio::task::JoinHandle<T>

1.9.0 · Source§

impl<T, A> UnwindSafe for Rc<T, A>

1.9.0 · Source§

impl<T, A> UnwindSafe for Arc<T, A>

1.80.0 · Source§

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

Auto implementors§

§

impl !UnwindSafe for BytesRejection

§

impl !UnwindSafe for ExtensionRejection

§

impl !UnwindSafe for FailedToBufferBody

§

impl !UnwindSafe for FormRejection

§

impl !UnwindSafe for JsonRejection

§

impl !UnwindSafe for QueryRejection

§

impl !UnwindSafe for RawFormRejection

§

impl !UnwindSafe for StringRejection

§

impl !UnwindSafe for rustmax::ctrlc::Error

§

impl !UnwindSafe for Target

§

impl !UnwindSafe for EventHandler

§

impl !UnwindSafe for ReadlineError

§

impl !UnwindSafe for rustmax::std::fs::TryLockError

§

impl !UnwindSafe for rustmax::tera::ErrorKind

§

impl !UnwindSafe for rustmax::axum::body::Body

§

impl !UnwindSafe for BodyDataStream

§

impl !UnwindSafe for HandleErrorFuture

§

impl !UnwindSafe for FailedToDeserializeForm

§

impl !UnwindSafe for FailedToDeserializeFormBody

§

impl !UnwindSafe for FailedToDeserializeQueryString

§

impl !UnwindSafe for InvalidUtf8

§

impl !UnwindSafe for JsonDataError

§

impl !UnwindSafe for JsonSyntaxError

§

impl !UnwindSafe for LengthLimitError

§

impl !UnwindSafe for MissingExtension

§

impl !UnwindSafe for UnknownBodyError

§

impl !UnwindSafe for rustmax::axum::middleware::future::FromFnResponseFuture

§

impl !UnwindSafe for rustmax::axum::middleware::future::MapRequestResponseFuture

§

impl !UnwindSafe for rustmax::axum::middleware::future::MapResponseResponseFuture

§

impl !UnwindSafe for rustmax::axum::middleware::Next

§

impl !UnwindSafe for ErrorResponse

§

impl !UnwindSafe for ResponseParts

§

impl !UnwindSafe for InfallibleRouteFuture

§

impl !UnwindSafe for rustmax::axum::Error

§

impl !UnwindSafe for Bindings

§

impl !UnwindSafe for rustmax::bindgen::Builder

§

impl !UnwindSafe for ValueParser

§

impl !UnwindSafe for Arg

§

impl !UnwindSafe for ArgMatches

§

impl !UnwindSafe for rustmax::clap::Command

§

impl !UnwindSafe for Collector

§

impl !UnwindSafe for Guard

§

impl !UnwindSafe for LocalHandle

§

impl !UnwindSafe for rustmax::env_logger::fmt::Formatter

§

impl !UnwindSafe for rustmax::env_logger::Builder

§

impl !UnwindSafe for Logger

§

impl !UnwindSafe for LocalPool

§

impl !UnwindSafe for LocalSpawner

§

impl !UnwindSafe for rustmax::futures::io::Error

§

impl !UnwindSafe for rustmax::http::request::Builder

§

impl !UnwindSafe for rustmax::http::request::Parts

§

impl !UnwindSafe for rustmax::http::response::Builder

§

impl !UnwindSafe for rustmax::http::response::Parts

§

impl !UnwindSafe for Extensions

§

impl !UnwindSafe for rustmax::hyper::body::Incoming

§

impl !UnwindSafe for rustmax::hyper::server::conn::http1::Builder

§

impl !UnwindSafe for rustmax::hyper::Error

§

impl !UnwindSafe for rustmax::hyper::upgrade::Upgraded

§

impl !UnwindSafe for rustmax::jiff::Error

§

impl !UnwindSafe for rustmax::prelude::future::AbortHandle

§

impl !UnwindSafe for AbortRegistration

§

impl !UnwindSafe for rustmax::proptest::test_runner::Config

§

impl !UnwindSafe for TestRunner

§

impl !UnwindSafe for ThreadRng

§

impl !UnwindSafe for ThreadBuilder

§

impl !UnwindSafe for ThreadPool

§

impl !UnwindSafe for ThreadPoolBuildError

§

impl !UnwindSafe for rustmax::reqwest::blocking::Body

§

impl !UnwindSafe for rustmax::reqwest::blocking::Client

§

impl !UnwindSafe for rustmax::reqwest::blocking::ClientBuilder

§

impl !UnwindSafe for rustmax::reqwest::blocking::Request

§

impl !UnwindSafe for rustmax::reqwest::blocking::RequestBuilder

§

impl !UnwindSafe for rustmax::reqwest::blocking::Response

§

impl !UnwindSafe for Action

§

impl !UnwindSafe for Policy

§

impl !UnwindSafe for rustmax::reqwest::Body

§

impl !UnwindSafe for rustmax::reqwest::Client

§

impl !UnwindSafe for rustmax::reqwest::ClientBuilder

§

impl !UnwindSafe for rustmax::reqwest::Error

§

impl !UnwindSafe for Proxy

§

impl !UnwindSafe for rustmax::reqwest::Request

§

impl !UnwindSafe for rustmax::reqwest::RequestBuilder

§

impl !UnwindSafe for rustmax::reqwest::Response

§

impl !UnwindSafe for rustmax::reqwest::Upgraded

§

impl !UnwindSafe for rustmax::serde_json::Error

§

impl !UnwindSafe for rustmax::std::process::Command

§

impl !UnwindSafe for PathPersistError

§

impl !UnwindSafe for rustmax::tera::Error

§

impl !UnwindSafe for Tera

§

impl !UnwindSafe for rustmax::tokio::fs::File

§

impl !UnwindSafe for rustmax::tokio::fs::ReadDir

§

impl !UnwindSafe for DuplexStream

§

impl !UnwindSafe for rustmax::tokio::process::Child

§

impl !UnwindSafe for rustmax::tokio::process::Command

§

impl !UnwindSafe for rustmax::tokio::runtime::Builder

§

impl !UnwindSafe for rustmax::tokio::signal::unix::Signal

§

impl !UnwindSafe for rustmax::tokio::sync::Barrier

§

impl !UnwindSafe for OwnedSemaphorePermit

§

impl !UnwindSafe for Semaphore

§

impl !UnwindSafe for JoinError

§

impl !UnwindSafe for LocalEnterGuard

§

impl !UnwindSafe for LocalSet

§

impl !UnwindSafe for Interval

§

impl !UnwindSafe for Sleep

§

impl !UnwindSafe for Discover

§

impl !UnwindSafe for ServiceError

§

impl !UnwindSafe for GlobalConcurrencyLimitLayer

§

impl !UnwindSafe for rustmax::walkdir::Error

§

impl !UnwindSafe for rustmax::walkdir::IntoIter

§

impl !UnwindSafe for WalkDir

§

impl !UnwindSafe for rustmax::xshell::Error

§

impl UnwindSafe for TryReserveErrorKind

§

impl UnwindSafe for rustmax::axum::extract::path::ErrorKind

§

impl UnwindSafe for MatchedPathRejection

§

impl UnwindSafe for PathRejection

§

impl UnwindSafe for RawPathParamsRejection

§

impl UnwindSafe for PrintFmt

§

impl UnwindSafe for ParseAlphabetError

§

impl UnwindSafe for DecodePaddingMode

§

impl UnwindSafe for DecodeError

§

impl UnwindSafe for DecodeSliceError

§

impl UnwindSafe for EncodeSliceError

§

impl UnwindSafe for DeriveTrait

§

impl UnwindSafe for DiscoveredItem

§

impl UnwindSafe for EnumVariantCustomBehavior

§

impl UnwindSafe for EnumVariantValue

§

impl UnwindSafe for CanDerive

§

impl UnwindSafe for IntKind

§

impl UnwindSafe for ItemKind

§

impl UnwindSafe for MacroParsingBehavior

§

impl UnwindSafe for Kind

§

impl UnwindSafe for TypeKind

§

impl UnwindSafe for rustmax::bindgen::Abi

§

impl UnwindSafe for AliasVariation

§

impl UnwindSafe for BindgenError

§

impl UnwindSafe for EnumVariation

§

impl UnwindSafe for FieldVisibilityKind

§

impl UnwindSafe for rustmax::bindgen::Formatter

§

impl UnwindSafe for MacroTypeVariation

§

impl UnwindSafe for NonCopyUnionStyle

§

impl UnwindSafe for RustEdition

§

impl UnwindSafe for BigEndian

§

impl UnwindSafe for LittleEndian

§

impl UnwindSafe for VsVers

§

impl UnwindSafe for Month

§

impl UnwindSafe for RoundingError

§

impl UnwindSafe for SecondsFormat

§

impl UnwindSafe for rustmax::chrono::Weekday

§

impl UnwindSafe for Colons

§

impl UnwindSafe for Fixed

§

impl UnwindSafe for Numeric

§

impl UnwindSafe for OffsetPrecision

§

impl UnwindSafe for Pad

§

impl UnwindSafe for ParseErrorKind

§

impl UnwindSafe for ArgPredicate

§

impl UnwindSafe for AnsiColor

§

impl UnwindSafe for rustmax::clap::builder::styling::Color

§

impl UnwindSafe for ArgAction

§

impl UnwindSafe for rustmax::clap::ColorChoice

§

impl UnwindSafe for ValueHint

§

impl UnwindSafe for ContextKind

§

impl UnwindSafe for ContextValue

§

impl UnwindSafe for rustmax::clap::error::ErrorKind

§

impl UnwindSafe for MatchesError

§

impl UnwindSafe for ValueSource

§

impl UnwindSafe for AsciiChar

§

impl UnwindSafe for Infallible

§

impl UnwindSafe for FromBytesWithNulError

§

impl UnwindSafe for rustmax::core::fmt::Alignment

§

impl UnwindSafe for DebugAsHex

§

impl UnwindSafe for rustmax::core::fmt::Sign

§

impl UnwindSafe for BasicBlock

§

impl UnwindSafe for UnwindTerminateReason

§

impl UnwindSafe for IpAddr

§

impl UnwindSafe for Ipv6MulticastScope

§

impl UnwindSafe for rustmax::core::net::SocketAddr

§

impl UnwindSafe for FpCategory

§

impl UnwindSafe for IntErrorKind

§

impl UnwindSafe for OneSidedRangeBound

§

impl UnwindSafe for GetDisjointMutError

§

impl UnwindSafe for SearchStep

§

impl UnwindSafe for rustmax::core::sync::atomic::Ordering

§

impl UnwindSafe for rustmax::crossbeam::channel::RecvTimeoutError

§

impl UnwindSafe for rustmax::crossbeam::channel::TryRecvError

§

impl UnwindSafe for SignalType

§

impl UnwindSafe for Opaque

§

impl UnwindSafe for Trivial

§

impl UnwindSafe for BinaryError

§

impl UnwindSafe for TimestampPrecision

§

impl UnwindSafe for WriteStyle

§

impl UnwindSafe for rustmax::futures::io::ErrorKind

§

impl UnwindSafe for SeekFrom

§

impl UnwindSafe for FromHexError

§

impl UnwindSafe for rustmax::itertools::Position

§

impl UnwindSafe for Era

§

impl UnwindSafe for rustmax::jiff::civil::Weekday

§

impl UnwindSafe for RoundMode

§

impl UnwindSafe for Unit

§

impl UnwindSafe for Designator

§

impl UnwindSafe for rustmax::jiff::fmt::friendly::Direction

§

impl UnwindSafe for FractionalUnit

§

impl UnwindSafe for rustmax::jiff::fmt::friendly::Spacing

§

impl UnwindSafe for Meridiem

§

impl UnwindSafe for PiecesOffset

§

impl UnwindSafe for AmbiguousOffset

§

impl UnwindSafe for Disambiguation

§

impl UnwindSafe for Dst

§

impl UnwindSafe for OffsetConflict

§

impl UnwindSafe for rustmax::json5::Error

§

impl UnwindSafe for DIR

§

impl UnwindSafe for FILE

§

impl UnwindSafe for c_void

§

impl UnwindSafe for timezone

§

impl UnwindSafe for tpacket_versions

§

impl UnwindSafe for rustmax::log::Level

§

impl UnwindSafe for LevelFilter

§

impl UnwindSafe for CompareResult

§

impl UnwindSafe for Needed

§

impl UnwindSafe for rustmax::nom::error::ErrorKind

§

impl UnwindSafe for Endianness

§

impl UnwindSafe for rustmax::num_bigint::Sign

§

impl UnwindSafe for rustmax::prelude::Ordering

§

impl UnwindSafe for PollNext

§

impl UnwindSafe for rustmax::proc_macro2::Delimiter

§

impl UnwindSafe for rustmax::proc_macro2::Spacing

§

impl UnwindSafe for rustmax::proc_macro2::TokenTree

§

impl UnwindSafe for ConversionErrorKind

§

impl UnwindSafe for rustmax::proc_macro::Delimiter

§

impl UnwindSafe for EscapeError

§

impl UnwindSafe for rustmax::proc_macro::Level

§

impl UnwindSafe for rustmax::proc_macro::Spacing

§

impl UnwindSafe for rustmax::proc_macro::TokenTree

§

impl UnwindSafe for rustmax::proptest::string::Error

§

impl UnwindSafe for FileFailurePersistence

§

impl UnwindSafe for RngAlgorithm

§

impl UnwindSafe for TestCaseError

§

impl UnwindSafe for BernoulliError

§

impl UnwindSafe for rustmax::rand::distr::uniform::Error

§

impl UnwindSafe for rustmax::rand::seq::WeightError

§

impl UnwindSafe for IndexVec

§

impl UnwindSafe for IndexVecIntoIter

§

impl UnwindSafe for rustmax::rayon::Yield

§

impl UnwindSafe for rustmax::regex::Error

§

impl UnwindSafe for Quote

§

impl UnwindSafe for BellStyle

§

impl UnwindSafe for Anchor

§

impl UnwindSafe for rustmax::rustyline::At

§

impl UnwindSafe for Behavior

§

impl UnwindSafe for CharSearch

§

impl UnwindSafe for rustmax::rustyline::Cmd

§

impl UnwindSafe for ColorMode

§

impl UnwindSafe for CompletionType

§

impl UnwindSafe for EditMode

§

impl UnwindSafe for rustmax::rustyline::Event

§

impl UnwindSafe for GraphemeClusterMode

§

impl UnwindSafe for HistoryDuplicates

§

impl UnwindSafe for InputMode

§

impl UnwindSafe for KeyCode

§

impl UnwindSafe for Movement

§

impl UnwindSafe for Word

§

impl UnwindSafe for rustmax::rustyline::error::Signal

§

impl UnwindSafe for CmdKind

§

impl UnwindSafe for SearchDirection

§

impl UnwindSafe for rustmax::rustyline::line_buffer::Direction

§

impl UnwindSafe for WordAction

§

impl UnwindSafe for ValidationResult

§

impl UnwindSafe for Op

§

impl UnwindSafe for rustmax::serde_json::Value

§

impl UnwindSafe for Category

§

impl UnwindSafe for CharEscape

§

impl UnwindSafe for TruncSide

§

impl UnwindSafe for InterfaceIndexOrAddress

§

impl UnwindSafe for BacktraceStatus

§

impl UnwindSafe for VarError

§

impl UnwindSafe for Shutdown

§

impl UnwindSafe for AncillaryError

§

impl UnwindSafe for BacktraceStyle

§

impl UnwindSafe for rustmax::std::sync::mpmc::RecvTimeoutError

§

impl UnwindSafe for rustmax::std::sync::mpmc::TryRecvError

§

impl UnwindSafe for AttrStyle

§

impl UnwindSafe for BinOp

§

impl UnwindSafe for CapturedParam

§

impl UnwindSafe for Data

§

impl UnwindSafe for rustmax::syn::Expr

§

impl UnwindSafe for FieldMutability

§

impl UnwindSafe for Fields

§

impl UnwindSafe for FnArg

§

impl UnwindSafe for ForeignItem

§

impl UnwindSafe for GenericArgument

§

impl UnwindSafe for GenericParam

§

impl UnwindSafe for ImplItem

§

impl UnwindSafe for ImplRestriction

§

impl UnwindSafe for rustmax::syn::Item

§

impl UnwindSafe for Lit

§

impl UnwindSafe for MacroDelimiter

§

impl UnwindSafe for Member

§

impl UnwindSafe for Meta

§

impl UnwindSafe for Pat

§

impl UnwindSafe for PathArguments

§

impl UnwindSafe for PointerMutability

§

impl UnwindSafe for RangeLimits

§

impl UnwindSafe for ReturnType

§

impl UnwindSafe for StaticMutability

§

impl UnwindSafe for Stmt

§

impl UnwindSafe for TraitBoundModifier

§

impl UnwindSafe for TraitItem

§

impl UnwindSafe for rustmax::syn::Type

§

impl UnwindSafe for TypeParamBound

§

impl UnwindSafe for UnOp

§

impl UnwindSafe for UseTree

§

impl UnwindSafe for Visibility

§

impl UnwindSafe for WherePredicate

§

impl UnwindSafe for SpooledData

§

impl UnwindSafe for ExprVal

§

impl UnwindSafe for LogicOperator

§

impl UnwindSafe for MathOperator

§

impl UnwindSafe for Node

§

impl UnwindSafe for rustmax::termcolor::Color

§

impl UnwindSafe for rustmax::termcolor::ColorChoice

§

impl UnwindSafe for RuntimeFlavor

§

impl UnwindSafe for rustmax::tokio::sync::broadcast::error::RecvError

§

impl UnwindSafe for rustmax::tokio::sync::broadcast::error::TryRecvError

§

impl UnwindSafe for TryAcquireError

§

impl UnwindSafe for rustmax::tokio::sync::mpsc::error::TryRecvError

§

impl UnwindSafe for rustmax::tokio::sync::oneshot::error::TryRecvError

§

impl UnwindSafe for MissedTickBehavior

§

impl UnwindSafe for rustmax::toml::Value

§

impl UnwindSafe for rustmax::toml::value::Offset

§

impl UnwindSafe for GraphemeIncomplete

§

impl UnwindSafe for Origin

§

impl UnwindSafe for rustmax::url::ParseError

§

impl UnwindSafe for rustmax::url::Position

§

impl UnwindSafe for SyntaxViolation

§

impl UnwindSafe for AHasher

§

impl UnwindSafe for rustmax::ahash::RandomState

§

impl UnwindSafe for Global

§

impl UnwindSafe for ByteString

§

impl UnwindSafe for UnorderedKeyError

§

impl UnwindSafe for TryReserveError

§

impl UnwindSafe for CString

§

impl UnwindSafe for FromVecWithNulError

§

impl UnwindSafe for IntoStringError

§

impl UnwindSafe for NulError

§

impl UnwindSafe for FromUtf8Error

§

impl UnwindSafe for FromUtf16Error

§

impl UnwindSafe for IntoChars

§

impl UnwindSafe for FailedToDeserializePathParams

§

impl UnwindSafe for InvalidUtf8InPathParam

§

impl UnwindSafe for InvalidFormContentType

§

impl UnwindSafe for MatchedPathMissing

§

impl UnwindSafe for MissingJsonContentType

§

impl UnwindSafe for MissingPathParams

§

impl UnwindSafe for NestedPathRejection

§

impl UnwindSafe for DefaultBodyLimit

§

impl UnwindSafe for MatchedPath

§

impl UnwindSafe for NestedPath

§

impl UnwindSafe for OriginalUri

§

impl UnwindSafe for RawForm

§

impl UnwindSafe for RawPathParams

§

impl UnwindSafe for RawQuery

§

impl UnwindSafe for rustmax::axum::response::sse::Event

§

impl UnwindSafe for KeepAlive

§

impl UnwindSafe for NoContent

§

impl UnwindSafe for Redirect

§

impl UnwindSafe for MethodFilter

§

impl UnwindSafe for rustmax::backtrace::Backtrace

§

impl UnwindSafe for rustmax::backtrace::BacktraceFrame

§

impl UnwindSafe for BacktraceSymbol

§

impl UnwindSafe for rustmax::backtrace::Frame

§

impl UnwindSafe for Symbol

§

impl UnwindSafe for Alphabet

§

impl UnwindSafe for DecodeMetadata

§

impl UnwindSafe for GeneralPurpose

§

impl UnwindSafe for GeneralPurposeConfig

§

impl UnwindSafe for DiscoveredItemId

§

impl UnwindSafe for Token

§

impl UnwindSafe for CargoCallbacks

§

impl UnwindSafe for ClangVersion

§

impl UnwindSafe for CodegenConfig

§

impl UnwindSafe for RustTarget

§

impl UnwindSafe for rustmax::bitflags::parser::ParseError

§

impl UnwindSafe for Hash

§

impl UnwindSafe for Hasher

§

impl UnwindSafe for HexError

§

impl UnwindSafe for OutputReader

§

impl UnwindSafe for UninitSlice

§

impl UnwindSafe for rustmax::bytes::Bytes

§

impl UnwindSafe for BytesMut

§

impl UnwindSafe for TryGetError

§

impl UnwindSafe for Build

§

impl UnwindSafe for rustmax::cc::Error

§

impl UnwindSafe for Tool

§

impl UnwindSafe for InternalFixed

§

impl UnwindSafe for InternalNumeric

§

impl UnwindSafe for OffsetFormat

§

impl UnwindSafe for Parsed

§

impl UnwindSafe for NaiveDateDaysIterator

§

impl UnwindSafe for NaiveDateWeeksIterator

§

impl UnwindSafe for Days

§

impl UnwindSafe for FixedOffset

§

impl UnwindSafe for IsoWeek

§

impl UnwindSafe for rustmax::chrono::Local

§

impl UnwindSafe for Months

§

impl UnwindSafe for NaiveDate

§

impl UnwindSafe for NaiveDateTime

§

impl UnwindSafe for NaiveTime

§

impl UnwindSafe for NaiveWeek

§

impl UnwindSafe for OutOfRange

§

impl UnwindSafe for OutOfRangeError

§

impl UnwindSafe for rustmax::chrono::ParseError

§

impl UnwindSafe for ParseMonthError

§

impl UnwindSafe for ParseWeekdayError

§

impl UnwindSafe for TimeDelta

§

impl UnwindSafe for Utc

§

impl UnwindSafe for BoolValueParser

§

impl UnwindSafe for BoolishValueParser

§

impl UnwindSafe for FalseyValueParser

§

impl UnwindSafe for NonEmptyStringValueParser

§

impl UnwindSafe for rustmax::clap::builder::OsStr

§

impl UnwindSafe for OsStringValueParser

§

impl UnwindSafe for PathBufValueParser

§

impl UnwindSafe for PossibleValue

§

impl UnwindSafe for PossibleValuesParser

§

impl UnwindSafe for Str

§

impl UnwindSafe for StringValueParser

§

impl UnwindSafe for StyledStr

§

impl UnwindSafe for Styles

§

impl UnwindSafe for UnknownArgumentValueParser

§

impl UnwindSafe for ValueRange

§

impl UnwindSafe for Ansi256Color

§

impl UnwindSafe for EffectIter

§

impl UnwindSafe for Effects

§

impl UnwindSafe for Reset

§

impl UnwindSafe for RgbColor

§

impl UnwindSafe for Style

§

impl UnwindSafe for KindFormatter

§

impl UnwindSafe for RichFormatter

§

impl UnwindSafe for ArgGroup

§

impl UnwindSafe for rustmax::clap::Id

§

impl UnwindSafe for AllocError

§

impl UnwindSafe for Layout

§

impl UnwindSafe for LayoutError

§

impl UnwindSafe for TypeId

§

impl UnwindSafe for CpuidResult

§

impl UnwindSafe for __m128

§

impl UnwindSafe for __m128bh

§

impl UnwindSafe for __m128d

§

impl UnwindSafe for __m128h

§

impl UnwindSafe for __m128i

§

impl UnwindSafe for __m256

§

impl UnwindSafe for __m256bh

§

impl UnwindSafe for __m256d

§

impl UnwindSafe for __m256h

§

impl UnwindSafe for __m256i

§

impl UnwindSafe for __m512

§

impl UnwindSafe for __m512bh

§

impl UnwindSafe for __m512d

§

impl UnwindSafe for __m512h

§

impl UnwindSafe for __m512i

§

impl UnwindSafe for bf16

§

impl UnwindSafe for TryFromSliceError

§

impl UnwindSafe for rustmax::core::ascii::EscapeDefault

§

impl UnwindSafe for ByteStr

§

impl UnwindSafe for BorrowError

§

impl UnwindSafe for BorrowMutError

§

impl UnwindSafe for CharTryFromError

§

impl UnwindSafe for DecodeUtf16Error

§

impl UnwindSafe for rustmax::core::char::EscapeDebug

§

impl UnwindSafe for rustmax::core::char::EscapeDefault

§

impl UnwindSafe for rustmax::core::char::EscapeUnicode

§

impl UnwindSafe for ParseCharError

§

impl UnwindSafe for ToLowercase

§

impl UnwindSafe for ToUppercase

§

impl UnwindSafe for TryFromCharError

§

impl UnwindSafe for CStr

§

impl UnwindSafe for FromBytesUntilNulError

§

impl UnwindSafe for rustmax::core::fmt::Error

§

impl UnwindSafe for FormattingOptions

§

impl UnwindSafe for SipHasher

§

impl UnwindSafe for ReturnToArg

§

impl UnwindSafe for UnwindActionArg

§

impl UnwindSafe for PhantomPinned

§

impl UnwindSafe for Assume

§

impl UnwindSafe for AddrParseError

§

impl UnwindSafe for Ipv4Addr

§

impl UnwindSafe for Ipv6Addr

§

impl UnwindSafe for SocketAddrV4

§

impl UnwindSafe for SocketAddrV6

§

impl UnwindSafe for ParseFloatError

§

impl UnwindSafe for ParseIntError

§

impl UnwindSafe for TryFromIntError

§

impl UnwindSafe for RangeFull

§

impl UnwindSafe for rustmax::core::ptr::Alignment

§

impl UnwindSafe for ParseBoolError

§

impl UnwindSafe for Utf8Error

§

impl UnwindSafe for AtomicBool

§

impl UnwindSafe for AtomicI8

§

impl UnwindSafe for AtomicI16

§

impl UnwindSafe for AtomicI32

§

impl UnwindSafe for AtomicI64

§

impl UnwindSafe for AtomicIsize

§

impl UnwindSafe for AtomicU8

§

impl UnwindSafe for AtomicU16

§

impl UnwindSafe for AtomicU32

§

impl UnwindSafe for AtomicU64

§

impl UnwindSafe for AtomicUsize

§

impl UnwindSafe for LocalWaker

§

impl UnwindSafe for TryFromFloatSecsError

§

impl UnwindSafe for ReadyTimeoutError

§

impl UnwindSafe for rustmax::crossbeam::channel::RecvError

§

impl UnwindSafe for SelectTimeoutError

§

impl UnwindSafe for TryReadyError

§

impl UnwindSafe for TrySelectError

§

impl UnwindSafe for Parker

§

impl UnwindSafe for Unparker

§

impl UnwindSafe for WaitGroup

§

impl UnwindSafe for Backoff

§

impl UnwindSafe for CxxString

§

impl UnwindSafe for Exception

§

impl UnwindSafe for rustmax::derive_more::FromStrError

§

impl UnwindSafe for rustmax::derive_more::UnitError

§

impl UnwindSafe for WrongVariantError

§

impl UnwindSafe for rustmax::env_logger::fmt::Timestamp

§

impl UnwindSafe for rustmax::futures::channel::mpsc::SendError

§

impl UnwindSafe for rustmax::futures::channel::mpsc::TryRecvError

§

impl UnwindSafe for Canceled

§

impl UnwindSafe for Enter

§

impl UnwindSafe for EnterError

§

impl UnwindSafe for rustmax::futures::io::Empty

§

impl UnwindSafe for rustmax::futures::io::Repeat

§

impl UnwindSafe for rustmax::futures::io::Sink

§

impl UnwindSafe for AtomicWaker

§

impl UnwindSafe for RawWaker

§

impl UnwindSafe for RawWakerVTable

§

impl UnwindSafe for SpawnError

§

impl UnwindSafe for Waker

§

impl UnwindSafe for InvalidHeaderName

§

impl UnwindSafe for InvalidHeaderValue

§

impl UnwindSafe for MaxSizeReached

§

impl UnwindSafe for ToStrError

§

impl UnwindSafe for InvalidMethod

§

impl UnwindSafe for InvalidStatusCode

§

impl UnwindSafe for rustmax::http::Error

§

impl UnwindSafe for HeaderName

§

impl UnwindSafe for HeaderValue

§

impl UnwindSafe for Method

§

impl UnwindSafe for StatusCode

§

impl UnwindSafe for Uri

§

impl UnwindSafe for rustmax::http::Version

§

impl UnwindSafe for Authority

§

impl UnwindSafe for rustmax::http::uri::Builder

§

impl UnwindSafe for InvalidUri

§

impl UnwindSafe for InvalidUriParts

§

impl UnwindSafe for rustmax::http::uri::Parts

§

impl UnwindSafe for PathAndQuery

§

impl UnwindSafe for Scheme

§

impl UnwindSafe for SizeHint

§

impl UnwindSafe for rustmax::hyper::client::conn::http1::Builder

§

impl UnwindSafe for rustmax::hyper::ext::Protocol

§

impl UnwindSafe for ReasonPhrase

§

impl UnwindSafe for OnUpgrade

§

impl UnwindSafe for rustmax::jiff::civil::Date

§

impl UnwindSafe for DateArithmetic

§

impl UnwindSafe for DateDifference

§

impl UnwindSafe for DateSeries

§

impl UnwindSafe for rustmax::jiff::civil::DateTime

§

impl UnwindSafe for DateTimeArithmetic

§

impl UnwindSafe for DateTimeDifference

§

impl UnwindSafe for DateTimeRound

§

impl UnwindSafe for DateTimeSeries

§

impl UnwindSafe for DateTimeWith

§

impl UnwindSafe for DateWith

§

impl UnwindSafe for ISOWeekDate

§

impl UnwindSafe for rustmax::jiff::civil::Time

§

impl UnwindSafe for TimeArithmetic

§

impl UnwindSafe for TimeDifference

§

impl UnwindSafe for TimeRound

§

impl UnwindSafe for TimeSeries

§

impl UnwindSafe for TimeWith

§

impl UnwindSafe for WeekdaysForward

§

impl UnwindSafe for WeekdaysReverse

§

impl UnwindSafe for rustmax::jiff::fmt::friendly::SpanParser

§

impl UnwindSafe for rustmax::jiff::fmt::friendly::SpanPrinter

§

impl UnwindSafe for rustmax::jiff::fmt::rfc2822::DateTimeParser

§

impl UnwindSafe for rustmax::jiff::fmt::rfc2822::DateTimePrinter

§

impl UnwindSafe for BrokenDownTime

§

impl UnwindSafe for rustmax::jiff::fmt::temporal::DateTimeParser

§

impl UnwindSafe for rustmax::jiff::fmt::temporal::DateTimePrinter

§

impl UnwindSafe for PiecesNumericOffset

§

impl UnwindSafe for rustmax::jiff::fmt::temporal::SpanParser

§

impl UnwindSafe for rustmax::jiff::fmt::temporal::SpanPrinter

§

impl UnwindSafe for SignedDuration

§

impl UnwindSafe for SignedDurationRound

§

impl UnwindSafe for rustmax::jiff::Span

§

impl UnwindSafe for SpanFieldwise

§

impl UnwindSafe for rustmax::jiff::Timestamp

§

impl UnwindSafe for TimestampArithmetic

§

impl UnwindSafe for TimestampDifference

§

impl UnwindSafe for TimestampDisplayWithOffset

§

impl UnwindSafe for TimestampRound

§

impl UnwindSafe for TimestampSeries

§

impl UnwindSafe for Zoned

§

impl UnwindSafe for ZonedArithmetic

§

impl UnwindSafe for ZonedRound

§

impl UnwindSafe for ZonedWith

§

impl UnwindSafe for AmbiguousTimestamp

§

impl UnwindSafe for AmbiguousZoned

§

impl UnwindSafe for rustmax::jiff::tz::Offset

§

impl UnwindSafe for OffsetArithmetic

§

impl UnwindSafe for OffsetRound

§

impl UnwindSafe for TimeZone

§

impl UnwindSafe for TimeZoneDatabase

§

impl UnwindSafe for rustmax::json5::Location

§

impl UnwindSafe for Dl_info

§

impl UnwindSafe for Elf32_Chdr

§

impl UnwindSafe for Elf32_Ehdr

§

impl UnwindSafe for Elf32_Phdr

§

impl UnwindSafe for Elf32_Shdr

§

impl UnwindSafe for Elf32_Sym

§

impl UnwindSafe for Elf64_Chdr

§

impl UnwindSafe for Elf64_Ehdr

§

impl UnwindSafe for Elf64_Phdr

§

impl UnwindSafe for Elf64_Shdr

§

impl UnwindSafe for Elf64_Sym

§

impl UnwindSafe for __c_anonymous__kernel_fsid_t

§

impl UnwindSafe for __c_anonymous_elf32_rel

§

impl UnwindSafe for __c_anonymous_elf32_rela

§

impl UnwindSafe for __c_anonymous_elf64_rel

§

impl UnwindSafe for __c_anonymous_elf64_rela

§

impl UnwindSafe for __c_anonymous_ifru_map

§

impl UnwindSafe for __c_anonymous_ptrace_syscall_info_entry

§

impl UnwindSafe for __c_anonymous_ptrace_syscall_info_exit

§

impl UnwindSafe for __c_anonymous_ptrace_syscall_info_seccomp

§

impl UnwindSafe for __c_anonymous_sockaddr_can_j1939

§

impl UnwindSafe for __c_anonymous_sockaddr_can_tp

§

impl UnwindSafe for __exit_status

§

impl UnwindSafe for __timeval

§

impl UnwindSafe for _libc_fpstate

§

impl UnwindSafe for _libc_fpxreg

§

impl UnwindSafe for _libc_xmmreg

§

impl UnwindSafe for addrinfo

§

impl UnwindSafe for af_alg_iv

§

impl UnwindSafe for aiocb

§

impl UnwindSafe for arpd_request

§

impl UnwindSafe for arphdr

§

impl UnwindSafe for arpreq

§

impl UnwindSafe for arpreq_old

§

impl UnwindSafe for can_filter

§

impl UnwindSafe for can_frame

§

impl UnwindSafe for canfd_frame

§

impl UnwindSafe for canxl_frame

§

impl UnwindSafe for clone_args

§

impl UnwindSafe for cmsghdr

§

impl UnwindSafe for cpu_set_t

§

impl UnwindSafe for dirent64

§

impl UnwindSafe for dirent

§

impl UnwindSafe for dl_phdr_info

§

impl UnwindSafe for dmabuf_cmsg

§

impl UnwindSafe for dmabuf_token

§

impl UnwindSafe for dqblk

§

impl UnwindSafe for epoll_event

§

impl UnwindSafe for epoll_params

§

impl UnwindSafe for fanotify_event_info_error

§

impl UnwindSafe for fanotify_event_info_fid

§

impl UnwindSafe for fanotify_event_info_header

§

impl UnwindSafe for fanotify_event_info_pidfd

§

impl UnwindSafe for fanotify_event_metadata

§

impl UnwindSafe for fanotify_response

§

impl UnwindSafe for fanout_args

§

impl UnwindSafe for fd_set

§

impl UnwindSafe for ff_condition_effect

§

impl UnwindSafe for ff_constant_effect

§

impl UnwindSafe for ff_effect

§

impl UnwindSafe for ff_envelope

§

impl UnwindSafe for ff_periodic_effect

§

impl UnwindSafe for ff_ramp_effect

§

impl UnwindSafe for ff_replay

§

impl UnwindSafe for ff_rumble_effect

§

impl UnwindSafe for ff_trigger

§

impl UnwindSafe for file_clone_range

§

impl UnwindSafe for flock64

§

impl UnwindSafe for flock

§

impl UnwindSafe for fpos64_t

§

impl UnwindSafe for fpos_t

§

impl UnwindSafe for fsid_t

§

impl UnwindSafe for genlmsghdr

§

impl UnwindSafe for glob64_t

§

impl UnwindSafe for glob_t

§

impl UnwindSafe for group

§

impl UnwindSafe for hostent

§

impl UnwindSafe for hwtstamp_config

§

impl UnwindSafe for if_nameindex

§

impl UnwindSafe for ifaddrs

§

impl UnwindSafe for ifconf

§

impl UnwindSafe for ifreq

§

impl UnwindSafe for in6_addr

§

impl UnwindSafe for in6_ifreq

§

impl UnwindSafe for in6_pktinfo

§

impl UnwindSafe for in6_rtmsg

§

impl UnwindSafe for in_addr

§

impl UnwindSafe for in_pktinfo

§

impl UnwindSafe for inotify_event

§

impl UnwindSafe for input_absinfo

§

impl UnwindSafe for input_event

§

impl UnwindSafe for input_id

§

impl UnwindSafe for input_keymap_entry

§

impl UnwindSafe for input_mask

§

impl UnwindSafe for iocb

§

impl UnwindSafe for iovec

§

impl UnwindSafe for ip_mreq

§

impl UnwindSafe for ip_mreq_source

§

impl UnwindSafe for ip_mreqn

§

impl UnwindSafe for ipc_perm

§

impl UnwindSafe for ipv6_mreq

§

impl UnwindSafe for itimerspec

§

impl UnwindSafe for itimerval

§

impl UnwindSafe for iw_discarded

§

impl UnwindSafe for iw_encode_ext

§

impl UnwindSafe for iw_event

§

impl UnwindSafe for iw_freq

§

impl UnwindSafe for iw_michaelmicfailure

§

impl UnwindSafe for iw_missed

§

impl UnwindSafe for iw_mlme

§

impl UnwindSafe for iw_param

§

impl UnwindSafe for iw_pmkid_cand

§

impl UnwindSafe for iw_pmksa

§

impl UnwindSafe for iw_point

§

impl UnwindSafe for iw_priv_args

§

impl UnwindSafe for iw_quality

§

impl UnwindSafe for iw_range

§

impl UnwindSafe for iw_scan_req

§

impl UnwindSafe for iw_statistics

§

impl UnwindSafe for iw_thrspy

§

impl UnwindSafe for iwreq

§

impl UnwindSafe for j1939_filter

§

impl UnwindSafe for lconv

§

impl UnwindSafe for linger

§

impl UnwindSafe for mallinfo2

§

impl UnwindSafe for mallinfo

§

impl UnwindSafe for max_align_t

§

impl UnwindSafe for mbstate_t

§

impl UnwindSafe for mcontext_t

§

impl UnwindSafe for mmsghdr

§

impl UnwindSafe for mnt_ns_info

§

impl UnwindSafe for mntent

§

impl UnwindSafe for mount_attr

§

impl UnwindSafe for mq_attr

§

impl UnwindSafe for msghdr

§

impl UnwindSafe for msginfo

§

impl UnwindSafe for msqid_ds

§

impl UnwindSafe for nl_mmap_hdr

§

impl UnwindSafe for nl_mmap_req

§

impl UnwindSafe for nl_pktinfo

§

impl UnwindSafe for nlattr

§

impl UnwindSafe for nlmsgerr

§

impl UnwindSafe for nlmsghdr

§

impl UnwindSafe for ntptimeval

§

impl UnwindSafe for open_how

§

impl UnwindSafe for option

§

impl UnwindSafe for packet_mreq

§

impl UnwindSafe for passwd

§

impl UnwindSafe for pidfd_info

§

impl UnwindSafe for pollfd

§

impl UnwindSafe for posix_spawn_file_actions_t

§

impl UnwindSafe for posix_spawnattr_t

§

impl UnwindSafe for protoent

§

impl UnwindSafe for pthread_attr_t

§

impl UnwindSafe for pthread_barrier_t

§

impl UnwindSafe for pthread_barrierattr_t

§

impl UnwindSafe for pthread_cond_t

§

impl UnwindSafe for pthread_condattr_t

§

impl UnwindSafe for pthread_mutex_t

§

impl UnwindSafe for pthread_mutexattr_t

§

impl UnwindSafe for pthread_rwlock_t

§

impl UnwindSafe for pthread_rwlockattr_t

§

impl UnwindSafe for ptp_clock_caps

§

impl UnwindSafe for ptp_clock_time

§

impl UnwindSafe for ptp_extts_event

§

impl UnwindSafe for ptp_extts_request

§

impl UnwindSafe for ptp_perout_request

§

impl UnwindSafe for ptp_pin_desc

§

impl UnwindSafe for ptp_sys_offset

§

impl UnwindSafe for ptp_sys_offset_extended

§

impl UnwindSafe for ptp_sys_offset_precise

§

impl UnwindSafe for ptrace_peeksiginfo_args

§

impl UnwindSafe for ptrace_rseq_configuration

§

impl UnwindSafe for ptrace_sud_config

§

impl UnwindSafe for ptrace_syscall_info

§

impl UnwindSafe for regex_t

§

impl UnwindSafe for regmatch_t

§

impl UnwindSafe for rlimit64

§

impl UnwindSafe for rlimit

§

impl UnwindSafe for rtentry

§

impl UnwindSafe for rusage

§

impl UnwindSafe for sched_attr

§

impl UnwindSafe for sched_param

§

impl UnwindSafe for sctp_authinfo

§

impl UnwindSafe for sctp_initmsg

§

impl UnwindSafe for sctp_nxtinfo

§

impl UnwindSafe for sctp_prinfo

§

impl UnwindSafe for sctp_rcvinfo

§

impl UnwindSafe for sctp_sndinfo

§

impl UnwindSafe for sctp_sndrcvinfo

§

impl UnwindSafe for seccomp_data

§

impl UnwindSafe for seccomp_notif

§

impl UnwindSafe for seccomp_notif_addfd

§

impl UnwindSafe for seccomp_notif_resp

§

impl UnwindSafe for seccomp_notif_sizes

§

impl UnwindSafe for sem_t

§

impl UnwindSafe for sembuf

§

impl UnwindSafe for semid_ds

§

impl UnwindSafe for seminfo

§

impl UnwindSafe for servent

§

impl UnwindSafe for shmid_ds

§

impl UnwindSafe for sigaction

§

impl UnwindSafe for sigevent

§

impl UnwindSafe for siginfo_t

§

impl UnwindSafe for signalfd_siginfo

§

impl UnwindSafe for sigset_t

§

impl UnwindSafe for sigval

§

impl UnwindSafe for sock_extended_err

§

impl UnwindSafe for sock_filter

§

impl UnwindSafe for sock_fprog

§

impl UnwindSafe for sock_txtime

§

impl UnwindSafe for sockaddr

§

impl UnwindSafe for sockaddr_alg

§

impl UnwindSafe for sockaddr_can

§

impl UnwindSafe for sockaddr_in6

§

impl UnwindSafe for sockaddr_in

§

impl UnwindSafe for sockaddr_ll

§

impl UnwindSafe for sockaddr_nl

§

impl UnwindSafe for sockaddr_pkt

§

impl UnwindSafe for sockaddr_storage

§

impl UnwindSafe for sockaddr_un

§

impl UnwindSafe for sockaddr_vm

§

impl UnwindSafe for sockaddr_xdp

§

impl UnwindSafe for spwd

§

impl UnwindSafe for stack_t

§

impl UnwindSafe for stat64

§

impl UnwindSafe for rustmax::libc::stat

§

impl UnwindSafe for statfs64

§

impl UnwindSafe for statfs

§

impl UnwindSafe for statvfs64

§

impl UnwindSafe for statvfs

§

impl UnwindSafe for statx

§

impl UnwindSafe for statx_timestamp

§

impl UnwindSafe for sysinfo

§

impl UnwindSafe for tcp_info

§

impl UnwindSafe for termios2

§

impl UnwindSafe for termios

§

impl UnwindSafe for timespec

§

impl UnwindSafe for timeval

§

impl UnwindSafe for timex

§

impl UnwindSafe for tls12_crypto_info_aes_ccm_128

§

impl UnwindSafe for tls12_crypto_info_aes_gcm_128

§

impl UnwindSafe for tls12_crypto_info_aes_gcm_256

§

impl UnwindSafe for tls12_crypto_info_aria_gcm_128

§

impl UnwindSafe for tls12_crypto_info_aria_gcm_256

§

impl UnwindSafe for tls12_crypto_info_chacha20_poly1305

§

impl UnwindSafe for tls12_crypto_info_sm4_ccm

§

impl UnwindSafe for tls12_crypto_info_sm4_gcm

§

impl UnwindSafe for tls_crypto_info

§

impl UnwindSafe for tm

§

impl UnwindSafe for tms

§

impl UnwindSafe for tpacket2_hdr

§

impl UnwindSafe for tpacket3_hdr

§

impl UnwindSafe for tpacket_auxdata

§

impl UnwindSafe for tpacket_bd_ts

§

impl UnwindSafe for tpacket_block_desc

§

impl UnwindSafe for tpacket_hdr

§

impl UnwindSafe for tpacket_hdr_v1

§

impl UnwindSafe for tpacket_hdr_variant1

§

impl UnwindSafe for tpacket_req3

§

impl UnwindSafe for tpacket_req

§

impl UnwindSafe for tpacket_rollover_stats

§

impl UnwindSafe for tpacket_stats

§

impl UnwindSafe for tpacket_stats_v3

§

impl UnwindSafe for ucontext_t

§

impl UnwindSafe for ucred

§

impl UnwindSafe for uinput_abs_setup

§

impl UnwindSafe for uinput_ff_erase

§

impl UnwindSafe for uinput_ff_upload

§

impl UnwindSafe for uinput_setup

§

impl UnwindSafe for uinput_user_dev

§

impl UnwindSafe for user

§

impl UnwindSafe for user_fpregs_struct

§

impl UnwindSafe for user_regs_struct

§

impl UnwindSafe for utimbuf

§

impl UnwindSafe for utmpx

§

impl UnwindSafe for utsname

§

impl UnwindSafe for winsize

§

impl UnwindSafe for xdp_desc

§

impl UnwindSafe for xdp_mmap_offsets

§

impl UnwindSafe for xdp_mmap_offsets_v1

§

impl UnwindSafe for xdp_options

§

impl UnwindSafe for xdp_ring_offset

§

impl UnwindSafe for xdp_ring_offset_v1

§

impl UnwindSafe for xdp_statistics

§

impl UnwindSafe for xdp_statistics_v1

§

impl UnwindSafe for xdp_umem_reg

§

impl UnwindSafe for xdp_umem_reg_v1

§

impl UnwindSafe for xsk_tx_metadata

§

impl UnwindSafe for xsk_tx_metadata_completion

§

impl UnwindSafe for xsk_tx_metadata_request

§

impl UnwindSafe for ParseLevelError

§

impl UnwindSafe for SetLoggerError

§

impl UnwindSafe for rustmax::mime::FromStrError

§

impl UnwindSafe for Mime

§

impl UnwindSafe for Check

§

impl UnwindSafe for Complete

§

impl UnwindSafe for Emit

§

impl UnwindSafe for SaturatingIterator

§

impl UnwindSafe for Streaming

§

impl UnwindSafe for BigInt

§

impl UnwindSafe for BigUint

§

impl UnwindSafe for ParseBigIntError

§

impl UnwindSafe for Aborted

§

impl UnwindSafe for String

§

impl UnwindSafe for rustmax::proc_macro2::extra::DelimSpan

§

impl UnwindSafe for rustmax::proc_macro2::Group

§

impl UnwindSafe for rustmax::proc_macro2::Ident

§

impl UnwindSafe for rustmax::proc_macro2::LexError

§

impl UnwindSafe for LineColumn

§

impl UnwindSafe for rustmax::proc_macro2::Literal

§

impl UnwindSafe for rustmax::proc_macro2::Punct

§

impl UnwindSafe for rustmax::proc_macro2::Span

§

impl UnwindSafe for rustmax::proc_macro2::TokenStream

§

impl UnwindSafe for rustmax::proc_macro2::token_stream::IntoIter

§

impl UnwindSafe for rustmax::proc_macro::Diagnostic

§

impl UnwindSafe for ExpandError

§

impl UnwindSafe for rustmax::proc_macro::Group

§

impl UnwindSafe for rustmax::proc_macro::Ident

§

impl UnwindSafe for rustmax::proc_macro::LexError

§

impl UnwindSafe for rustmax::proc_macro::Literal

§

impl UnwindSafe for rustmax::proc_macro::Punct

§

impl UnwindSafe for rustmax::proc_macro::Span

§

impl UnwindSafe for rustmax::proc_macro::TokenStream

§

impl UnwindSafe for rustmax::proc_macro::token_stream::IntoIter

§

impl UnwindSafe for VarBitSet

§

impl UnwindSafe for rustmax::proptest::bool::Any

§

impl UnwindSafe for BoolValueTree

§

impl UnwindSafe for Weighted

§

impl UnwindSafe for CharValueTree

§

impl UnwindSafe for SizeRange

§

impl UnwindSafe for rustmax::proptest::num::f32::Any

§

impl UnwindSafe for rustmax::proptest::num::f32::BinarySearch

§

impl UnwindSafe for rustmax::proptest::num::f64::Any

§

impl UnwindSafe for rustmax::proptest::num::f64::BinarySearch

§

impl UnwindSafe for rustmax::proptest::num::i8::Any

§

impl UnwindSafe for rustmax::proptest::num::i8::BinarySearch

§

impl UnwindSafe for rustmax::proptest::num::i16::Any

§

impl UnwindSafe for rustmax::proptest::num::i16::BinarySearch

§

impl UnwindSafe for rustmax::proptest::num::i32::Any

§

impl UnwindSafe for rustmax::proptest::num::i32::BinarySearch

§

impl UnwindSafe for rustmax::proptest::num::i64::Any

§

impl UnwindSafe for rustmax::proptest::num::i64::BinarySearch

§

impl UnwindSafe for rustmax::proptest::num::i128::Any

§

impl UnwindSafe for rustmax::proptest::num::i128::BinarySearch

§

impl UnwindSafe for rustmax::proptest::num::isize::Any

§

impl UnwindSafe for rustmax::proptest::num::isize::BinarySearch

§

impl UnwindSafe for rustmax::proptest::num::u8::Any

§

impl UnwindSafe for rustmax::proptest::num::u8::BinarySearch

§

impl UnwindSafe for rustmax::proptest::num::u16::Any

§

impl UnwindSafe for rustmax::proptest::num::u16::BinarySearch

§

impl UnwindSafe for rustmax::proptest::num::u32::Any

§

impl UnwindSafe for rustmax::proptest::num::u32::BinarySearch

§

impl UnwindSafe for rustmax::proptest::num::u64::Any

§

impl UnwindSafe for rustmax::proptest::num::u64::BinarySearch

§

impl UnwindSafe for rustmax::proptest::num::u128::Any

§

impl UnwindSafe for rustmax::proptest::num::u128::BinarySearch

§

impl UnwindSafe for rustmax::proptest::num::usize::Any

§

impl UnwindSafe for rustmax::proptest::num::usize::BinarySearch

§

impl UnwindSafe for Probability

§

impl UnwindSafe for PathParams

§

impl UnwindSafe for rustmax::proptest::sample::Index

§

impl UnwindSafe for IndexStrategy

§

impl UnwindSafe for IndexValueTree

§

impl UnwindSafe for Selector

§

impl UnwindSafe for SelectorStrategy

§

impl UnwindSafe for SelectorValueTree

§

impl UnwindSafe for CheckStrategySanityOptions

§

impl UnwindSafe for StringParam

§

impl UnwindSafe for MapFailurePersistence

§

impl UnwindSafe for PersistedSeed

§

impl UnwindSafe for Reason

§

impl UnwindSafe for TestRng

§

impl UnwindSafe for rustmax::rand::distr::slice::Empty

§

impl UnwindSafe for Alphanumeric

§

impl UnwindSafe for Bernoulli

§

impl UnwindSafe for Open01

§

impl UnwindSafe for OpenClosed01

§

impl UnwindSafe for StandardUniform

§

impl UnwindSafe for UniformChar

§

impl UnwindSafe for UniformDuration

§

impl UnwindSafe for UniformUsize

§

impl UnwindSafe for StdRng

§

impl UnwindSafe for StepRng

§

impl UnwindSafe for OsRng

§

impl UnwindSafe for OsError

§

impl UnwindSafe for ChaCha8Core

§

impl UnwindSafe for ChaCha8Rng

§

impl UnwindSafe for ChaCha12Core

§

impl UnwindSafe for ChaCha12Rng

§

impl UnwindSafe for ChaCha20Core

§

impl UnwindSafe for ChaCha20Rng

§

impl UnwindSafe for Lcg64Xsh32

§

impl UnwindSafe for Lcg128CmDxsm64

§

impl UnwindSafe for Lcg128Xsl64

§

impl UnwindSafe for Mcg128Xsl64

§

impl UnwindSafe for FnContext

§

impl UnwindSafe for rustmax::regex::bytes::CaptureLocations

§

impl UnwindSafe for rustmax::regex::bytes::Regex

§

impl UnwindSafe for rustmax::regex::bytes::RegexBuilder

§

impl UnwindSafe for rustmax::regex::bytes::RegexSet

§

impl UnwindSafe for rustmax::regex::bytes::RegexSetBuilder

§

impl UnwindSafe for rustmax::regex::bytes::SetMatches

§

impl UnwindSafe for rustmax::regex::bytes::SetMatchesIntoIter

§

impl UnwindSafe for rustmax::regex::CaptureLocations

§

impl UnwindSafe for rustmax::regex::Regex

§

impl UnwindSafe for rustmax::regex::RegexBuilder

§

impl UnwindSafe for rustmax::regex::RegexSet

§

impl UnwindSafe for rustmax::regex::RegexSetBuilder

§

impl UnwindSafe for rustmax::regex::SetMatches

§

impl UnwindSafe for rustmax::regex::SetMatchesIntoIter

§

impl UnwindSafe for rustmax::reqwest::dns::Name

§

impl UnwindSafe for Certificate

§

impl UnwindSafe for rustmax::reqwest::Identity

§

impl UnwindSafe for NoProxy

§

impl UnwindSafe for Url

§

impl UnwindSafe for TlsInfo

§

impl UnwindSafe for rustmax::reqwest::tls::Version

§

impl UnwindSafe for FilenameCompleter

§

impl UnwindSafe for rustmax::rustyline::completion::Pair

§

impl UnwindSafe for rustmax::rustyline::config::Builder

§

impl UnwindSafe for MatchingBracketHighlighter

§

impl UnwindSafe for HistoryHinter

§

impl UnwindSafe for FileHistory

§

impl UnwindSafe for MemHistory

§

impl UnwindSafe for LineBuffer

§

impl UnwindSafe for Changeset

§

impl UnwindSafe for rustmax::rustyline::Config

§

impl UnwindSafe for KeyEvent

§

impl UnwindSafe for Modifiers

§

impl UnwindSafe for MatchingBracketValidator

§

impl UnwindSafe for BuildMetadata

§

impl UnwindSafe for Comparator

§

impl UnwindSafe for rustmax::semver::Error

§

impl UnwindSafe for Prerelease

§

impl UnwindSafe for rustmax::semver::Version

§

impl UnwindSafe for VersionReq

§

impl UnwindSafe for IgnoredAny

§

impl UnwindSafe for rustmax::serde::de::value::Error

§

impl UnwindSafe for rustmax::serde_json::map::IntoIter

§

impl UnwindSafe for rustmax::serde_json::map::IntoValues

§

impl UnwindSafe for CompactFormatter

§

impl UnwindSafe for Number

§

impl UnwindSafe for RawValue

§

impl UnwindSafe for rustmax::serde_json::value::Serializer

§

impl UnwindSafe for ATerm

§

impl UnwindSafe for B0

§

impl UnwindSafe for B1

§

impl UnwindSafe for Equal

§

impl UnwindSafe for Greater

§

impl UnwindSafe for Less

§

impl UnwindSafe for UTerm

§

impl UnwindSafe for Z0

§

impl UnwindSafe for Eager

§

impl UnwindSafe for rustmax::sha2::digest::block_buffer::Lazy

§

impl UnwindSafe for InvalidLength

§

impl UnwindSafe for InvalidBufferSize

§

impl UnwindSafe for InvalidOutputSize

§

impl UnwindSafe for Sha256VarCore

§

impl UnwindSafe for Sha512VarCore

§

impl UnwindSafe for Domain

§

impl UnwindSafe for rustmax::socket2::Protocol

§

impl UnwindSafe for RecvFlags

§

impl UnwindSafe for SockAddr

§

impl UnwindSafe for SockAddrStorage

§

impl UnwindSafe for Socket

§

impl UnwindSafe for TcpKeepalive

§

impl UnwindSafe for rustmax::socket2::Type

§

impl UnwindSafe for System

§

impl UnwindSafe for rustmax::std::backtrace::Backtrace

§

impl UnwindSafe for rustmax::std::backtrace::BacktraceFrame

§

impl UnwindSafe for Args

§

impl UnwindSafe for ArgsOs

§

impl UnwindSafe for JoinPathsError

§

impl UnwindSafe for Vars

§

impl UnwindSafe for VarsOs

§

impl UnwindSafe for rustmax::std::ffi::OsStr

§

impl UnwindSafe for OsString

§

impl UnwindSafe for rustmax::std::fs::DirBuilder

§

impl UnwindSafe for rustmax::std::fs::DirEntry

§

impl UnwindSafe for rustmax::std::fs::File

§

impl UnwindSafe for FileTimes

§

impl UnwindSafe for FileType

§

impl UnwindSafe for rustmax::std::fs::Metadata

§

impl UnwindSafe for rustmax::std::fs::OpenOptions

§

impl UnwindSafe for Permissions

§

impl UnwindSafe for rustmax::std::fs::ReadDir

§

impl UnwindSafe for DefaultHasher

§

impl UnwindSafe for rustmax::std::hash::RandomState

§

impl UnwindSafe for rustmax::std::io::Empty

§

impl UnwindSafe for PipeReader

§

impl UnwindSafe for PipeWriter

§

impl UnwindSafe for rustmax::std::io::Repeat

§

impl UnwindSafe for rustmax::std::io::Sink

§

impl UnwindSafe for rustmax::std::io::Stdin

§

impl UnwindSafe for WriterPanicked

§

impl UnwindSafe for IntoIncoming

§

impl UnwindSafe for rustmax::std::net::TcpListener

§

impl UnwindSafe for rustmax::std::net::TcpStream

§

impl UnwindSafe for rustmax::std::net::UdpSocket

§

impl UnwindSafe for OwnedFd

§

impl UnwindSafe for PidFd

§

impl UnwindSafe for rustmax::std::os::linux::raw::stat

§

impl UnwindSafe for rustmax::std::os::unix::net::SocketAddr

§

impl UnwindSafe for SocketCred

§

impl UnwindSafe for rustmax::std::os::unix::net::UCred

§

impl UnwindSafe for rustmax::std::os::unix::net::UnixDatagram

§

impl UnwindSafe for rustmax::std::os::unix::net::UnixListener

§

impl UnwindSafe for rustmax::std::os::unix::net::UnixStream

§

impl UnwindSafe for rustmax::std::path::Path

§

impl UnwindSafe for PathBuf

§

impl UnwindSafe for StripPrefixError

§

impl UnwindSafe for rustmax::std::process::Child

§

impl UnwindSafe for rustmax::std::process::ChildStderr

§

impl UnwindSafe for rustmax::std::process::ChildStdin

§

impl UnwindSafe for rustmax::std::process::ChildStdout

§

impl UnwindSafe for ExitCode

§

impl UnwindSafe for ExitStatus

§

impl UnwindSafe for ExitStatusError

§

impl UnwindSafe for Output

§

impl UnwindSafe for Stdio

§

impl UnwindSafe for DefaultRandomSource

§

impl UnwindSafe for rustmax::std::sync::mpmc::RecvError

§

impl UnwindSafe for rustmax::std::sync::Barrier

§

impl UnwindSafe for rustmax::std::sync::BarrierWaitResult

§

impl UnwindSafe for OnceState

§

impl UnwindSafe for WaitTimeoutResult

§

impl UnwindSafe for AccessError

§

impl UnwindSafe for rustmax::std::thread::Builder

§

impl UnwindSafe for Thread

§

impl UnwindSafe for ThreadId

§

impl UnwindSafe for rustmax::std::time::Instant

§

impl UnwindSafe for SystemTime

§

impl UnwindSafe for SystemTimeError

§

impl UnwindSafe for TokenBuffer

§

impl UnwindSafe for End

§

impl UnwindSafe for Nothing

§

impl UnwindSafe for rustmax::syn::Abi

§

impl UnwindSafe for AngleBracketedGenericArguments

§

impl UnwindSafe for Arm

§

impl UnwindSafe for AssocConst

§

impl UnwindSafe for AssocType

§

impl UnwindSafe for Attribute

§

impl UnwindSafe for BareFnArg

§

impl UnwindSafe for BareVariadic

§

impl UnwindSafe for rustmax::syn::Block

§

impl UnwindSafe for BoundLifetimes

§

impl UnwindSafe for ConstParam

§

impl UnwindSafe for Constraint

§

impl UnwindSafe for DataEnum

§

impl UnwindSafe for DataStruct

§

impl UnwindSafe for DataUnion

§

impl UnwindSafe for DeriveInput

§

impl UnwindSafe for rustmax::syn::Error

§

impl UnwindSafe for ExprArray

§

impl UnwindSafe for ExprAssign

§

impl UnwindSafe for ExprAsync

§

impl UnwindSafe for ExprAwait

§

impl UnwindSafe for ExprBinary

§

impl UnwindSafe for ExprBlock

§

impl UnwindSafe for ExprBreak

§

impl UnwindSafe for ExprCall

§

impl UnwindSafe for ExprCast

§

impl UnwindSafe for ExprClosure

§

impl UnwindSafe for ExprConst

§

impl UnwindSafe for ExprContinue

§

impl UnwindSafe for ExprField

§

impl UnwindSafe for ExprForLoop

§

impl UnwindSafe for ExprGroup

§

impl UnwindSafe for ExprIf

§

impl UnwindSafe for ExprIndex

§

impl UnwindSafe for ExprInfer

§

impl UnwindSafe for ExprLet

§

impl UnwindSafe for ExprLit

§

impl UnwindSafe for ExprLoop

§

impl UnwindSafe for ExprMacro

§

impl UnwindSafe for ExprMatch

§

impl UnwindSafe for ExprMethodCall

§

impl UnwindSafe for ExprParen

§

impl UnwindSafe for ExprPath

§

impl UnwindSafe for ExprRange

§

impl UnwindSafe for ExprRawAddr

§

impl UnwindSafe for ExprReference

§

impl UnwindSafe for ExprRepeat

§

impl UnwindSafe for ExprReturn

§

impl UnwindSafe for ExprStruct

§

impl UnwindSafe for ExprTry

§

impl UnwindSafe for ExprTryBlock

§

impl UnwindSafe for ExprTuple

§

impl UnwindSafe for ExprUnary

§

impl UnwindSafe for ExprUnsafe

§

impl UnwindSafe for ExprWhile

§

impl UnwindSafe for ExprYield

§

impl UnwindSafe for Field

§

impl UnwindSafe for FieldPat

§

impl UnwindSafe for FieldValue

§

impl UnwindSafe for FieldsNamed

§

impl UnwindSafe for FieldsUnnamed

§

impl UnwindSafe for rustmax::syn::File

§

impl UnwindSafe for ForeignItemFn

§

impl UnwindSafe for ForeignItemMacro

§

impl UnwindSafe for ForeignItemStatic

§

impl UnwindSafe for ForeignItemType

§

impl UnwindSafe for Generics

§

impl UnwindSafe for ImplItemConst

§

impl UnwindSafe for ImplItemFn

§

impl UnwindSafe for ImplItemMacro

§

impl UnwindSafe for ImplItemType

§

impl UnwindSafe for rustmax::syn::Index

§

impl UnwindSafe for ItemConst

§

impl UnwindSafe for ItemEnum

§

impl UnwindSafe for ItemExternCrate

§

impl UnwindSafe for ItemFn

§

impl UnwindSafe for ItemForeignMod

§

impl UnwindSafe for ItemImpl

§

impl UnwindSafe for ItemMacro

§

impl UnwindSafe for ItemMod

§

impl UnwindSafe for ItemStatic

§

impl UnwindSafe for ItemStruct

§

impl UnwindSafe for ItemTrait

§

impl UnwindSafe for ItemTraitAlias

§

impl UnwindSafe for ItemType

§

impl UnwindSafe for ItemUnion

§

impl UnwindSafe for ItemUse

§

impl UnwindSafe for Label

§

impl UnwindSafe for Lifetime

§

impl UnwindSafe for LifetimeParam

§

impl UnwindSafe for LitBool

§

impl UnwindSafe for LitByte

§

impl UnwindSafe for LitByteStr

§

impl UnwindSafe for LitCStr

§

impl UnwindSafe for LitChar

§

impl UnwindSafe for LitFloat

§

impl UnwindSafe for LitInt

§

impl UnwindSafe for LitStr

§

impl UnwindSafe for rustmax::syn::Local

§

impl UnwindSafe for LocalInit

§

impl UnwindSafe for rustmax::syn::Macro

§

impl UnwindSafe for MetaList

§

impl UnwindSafe for MetaNameValue

§

impl UnwindSafe for ParenthesizedGenericArguments

§

impl UnwindSafe for PatIdent

§

impl UnwindSafe for PatOr

§

impl UnwindSafe for PatParen

§

impl UnwindSafe for PatReference

§

impl UnwindSafe for PatRest

§

impl UnwindSafe for PatSlice

§

impl UnwindSafe for PatStruct

§

impl UnwindSafe for PatTuple

§

impl UnwindSafe for PatTupleStruct

§

impl UnwindSafe for PatType

§

impl UnwindSafe for PatWild

§

impl UnwindSafe for rustmax::syn::Path

§

impl UnwindSafe for PathSegment

§

impl UnwindSafe for PreciseCapture

§

impl UnwindSafe for PredicateLifetime

§

impl UnwindSafe for PredicateType

§

impl UnwindSafe for QSelf

§

impl UnwindSafe for rustmax::syn::Receiver

§

impl UnwindSafe for Signature

§

impl UnwindSafe for StmtMacro

§

impl UnwindSafe for TraitBound

§

impl UnwindSafe for TraitItemConst

§

impl UnwindSafe for TraitItemFn

§

impl UnwindSafe for TraitItemMacro

§

impl UnwindSafe for TraitItemType

§

impl UnwindSafe for TypeArray

§

impl UnwindSafe for TypeBareFn

§

impl UnwindSafe for TypeGroup

§

impl UnwindSafe for TypeImplTrait

§

impl UnwindSafe for TypeInfer

§

impl UnwindSafe for TypeMacro

§

impl UnwindSafe for TypeNever

§

impl UnwindSafe for TypeParam

§

impl UnwindSafe for TypeParen

§

impl UnwindSafe for TypePath

§

impl UnwindSafe for TypePtr

§

impl UnwindSafe for TypeReference

§

impl UnwindSafe for TypeSlice

§

impl UnwindSafe for TypeTraitObject

§

impl UnwindSafe for TypeTuple

§

impl UnwindSafe for UseGlob

§

impl UnwindSafe for UseGroup

§

impl UnwindSafe for UseName

§

impl UnwindSafe for UsePath

§

impl UnwindSafe for UseRename

§

impl UnwindSafe for Variadic

§

impl UnwindSafe for Variant

§

impl UnwindSafe for VisRestricted

§

impl UnwindSafe for WhereClause

§

impl UnwindSafe for Abstract

§

impl UnwindSafe for rustmax::syn::token::And

§

impl UnwindSafe for AndAnd

§

impl UnwindSafe for AndEq

§

impl UnwindSafe for As

§

impl UnwindSafe for Async

§

impl UnwindSafe for rustmax::syn::token::At

§

impl UnwindSafe for Auto

§

impl UnwindSafe for Await

§

impl UnwindSafe for Become

§

impl UnwindSafe for rustmax::syn::token::Box

§

impl UnwindSafe for Brace

§

impl UnwindSafe for Bracket

§

impl UnwindSafe for Break

§

impl UnwindSafe for Caret

§

impl UnwindSafe for CaretEq

§

impl UnwindSafe for Colon

§

impl UnwindSafe for Comma

§

impl UnwindSafe for Const

§

impl UnwindSafe for Continue

§

impl UnwindSafe for Crate

§

impl UnwindSafe for Default

§

impl UnwindSafe for Do

§

impl UnwindSafe for Dollar

§

impl UnwindSafe for Dot

§

impl UnwindSafe for DotDot

§

impl UnwindSafe for DotDotDot

§

impl UnwindSafe for DotDotEq

§

impl UnwindSafe for Dyn

§

impl UnwindSafe for Else

§

impl UnwindSafe for Enum

§

impl UnwindSafe for Eq

§

impl UnwindSafe for EqEq

§

impl UnwindSafe for Extern

§

impl UnwindSafe for FatArrow

§

impl UnwindSafe for Final

§

impl UnwindSafe for Fn

§

impl UnwindSafe for For

§

impl UnwindSafe for Ge

§

impl UnwindSafe for rustmax::syn::token::Group

§

impl UnwindSafe for Gt

§

impl UnwindSafe for rustmax::syn::token::If

§

impl UnwindSafe for Impl

§

impl UnwindSafe for rustmax::syn::token::In

§

impl UnwindSafe for LArrow

§

impl UnwindSafe for Le

§

impl UnwindSafe for Let

§

impl UnwindSafe for Loop

§

impl UnwindSafe for Lt

§

impl UnwindSafe for rustmax::syn::token::Macro

§

impl UnwindSafe for rustmax::syn::token::Match

§

impl UnwindSafe for Minus

§

impl UnwindSafe for MinusEq

§

impl UnwindSafe for Mod

§

impl UnwindSafe for Move

§

impl UnwindSafe for Mut

§

impl UnwindSafe for Ne

§

impl UnwindSafe for rustmax::syn::token::Not

§

impl UnwindSafe for rustmax::syn::token::Or

§

impl UnwindSafe for OrEq

§

impl UnwindSafe for OrOr

§

impl UnwindSafe for Override

§

impl UnwindSafe for Paren

§

impl UnwindSafe for PathSep

§

impl UnwindSafe for Percent

§

impl UnwindSafe for PercentEq

§

impl UnwindSafe for Plus

§

impl UnwindSafe for PlusEq

§

impl UnwindSafe for Pound

§

impl UnwindSafe for Priv

§

impl UnwindSafe for Pub

§

impl UnwindSafe for Question

§

impl UnwindSafe for RArrow

§

impl UnwindSafe for Raw

§

impl UnwindSafe for rustmax::syn::token::Ref

§

impl UnwindSafe for Return

§

impl UnwindSafe for SelfType

§

impl UnwindSafe for SelfValue

§

impl UnwindSafe for Semi

§

impl UnwindSafe for Shl

§

impl UnwindSafe for ShlEq

§

impl UnwindSafe for Shr

§

impl UnwindSafe for ShrEq

§

impl UnwindSafe for Slash

§

impl UnwindSafe for SlashEq

§

impl UnwindSafe for Star

§

impl UnwindSafe for StarEq

§

impl UnwindSafe for Static

§

impl UnwindSafe for Struct

§

impl UnwindSafe for Super

§

impl UnwindSafe for Tilde

§

impl UnwindSafe for Trait

§

impl UnwindSafe for Try

§

impl UnwindSafe for rustmax::syn::token::Type

§

impl UnwindSafe for Typeof

§

impl UnwindSafe for Underscore

§

impl UnwindSafe for rustmax::syn::token::Union

§

impl UnwindSafe for Unsafe

§

impl UnwindSafe for Unsized

§

impl UnwindSafe for Use

§

impl UnwindSafe for Virtual

§

impl UnwindSafe for Where

§

impl UnwindSafe for While

§

impl UnwindSafe for rustmax::syn::token::Yield

§

impl UnwindSafe for SpooledTempFile

§

impl UnwindSafe for rustmax::tempfile::TempDir

§

impl UnwindSafe for TempPath

§

impl UnwindSafe for rustmax::tera::ast::Block

§

impl UnwindSafe for rustmax::tera::ast::Expr

§

impl UnwindSafe for FilterSection

§

impl UnwindSafe for Forloop

§

impl UnwindSafe for FunctionCall

§

impl UnwindSafe for rustmax::tera::ast::If

§

impl UnwindSafe for rustmax::tera::ast::In

§

impl UnwindSafe for LogicExpr

§

impl UnwindSafe for MacroCall

§

impl UnwindSafe for MacroDefinition

§

impl UnwindSafe for MathExpr

§

impl UnwindSafe for Set

§

impl UnwindSafe for StringConcat

§

impl UnwindSafe for Test

§

impl UnwindSafe for WS

§

impl UnwindSafe for rustmax::tera::Context

§

impl UnwindSafe for Template

§

impl UnwindSafe for rustmax::termcolor::Buffer

§

impl UnwindSafe for BufferWriter

§

impl UnwindSafe for BufferedStandardStream

§

impl UnwindSafe for ColorChoiceParseError

§

impl UnwindSafe for ColorSpec

§

impl UnwindSafe for ParseColorError

§

impl UnwindSafe for StandardStream

§

impl UnwindSafe for rustmax::tokio::fs::DirBuilder

§

impl UnwindSafe for rustmax::tokio::fs::DirEntry

§

impl UnwindSafe for rustmax::tokio::fs::OpenOptions

§

impl UnwindSafe for rustmax::tokio::io::Empty

§

impl UnwindSafe for Interest

§

impl UnwindSafe for rustmax::tokio::io::Ready

§

impl UnwindSafe for rustmax::tokio::io::Repeat

§

impl UnwindSafe for SimplexStream

§

impl UnwindSafe for rustmax::tokio::io::Sink

§

impl UnwindSafe for rustmax::tokio::io::Stderr

§

impl UnwindSafe for rustmax::tokio::io::Stdin

§

impl UnwindSafe for rustmax::tokio::io::Stdout

§

impl UnwindSafe for TryIoError

§

impl UnwindSafe for rustmax::tokio::net::TcpListener

§

impl UnwindSafe for TcpSocket

§

impl UnwindSafe for rustmax::tokio::net::TcpStream

§

impl UnwindSafe for rustmax::tokio::net::UdpSocket

§

impl UnwindSafe for rustmax::tokio::net::UnixDatagram

§

impl UnwindSafe for rustmax::tokio::net::UnixListener

§

impl UnwindSafe for UnixSocket

§

impl UnwindSafe for rustmax::tokio::net::UnixStream

§

impl UnwindSafe for rustmax::tokio::net::tcp::OwnedReadHalf

§

impl UnwindSafe for rustmax::tokio::net::tcp::OwnedWriteHalf

§

impl UnwindSafe for rustmax::tokio::net::tcp::ReuniteError

§

impl UnwindSafe for rustmax::tokio::net::unix::pipe::OpenOptions

§

impl UnwindSafe for rustmax::tokio::net::unix::pipe::Receiver

§

impl UnwindSafe for rustmax::tokio::net::unix::pipe::Sender

§

impl UnwindSafe for rustmax::tokio::net::unix::OwnedReadHalf

§

impl UnwindSafe for rustmax::tokio::net::unix::OwnedWriteHalf

§

impl UnwindSafe for rustmax::tokio::net::unix::ReuniteError

§

impl UnwindSafe for rustmax::tokio::net::unix::SocketAddr

§

impl UnwindSafe for rustmax::tokio::net::unix::UCred

§

impl UnwindSafe for rustmax::tokio::process::ChildStderr

§

impl UnwindSafe for rustmax::tokio::process::ChildStdin

§

impl UnwindSafe for rustmax::tokio::process::ChildStdout

§

impl UnwindSafe for RuntimeMetrics

§

impl UnwindSafe for TryCurrentError

§

impl UnwindSafe for SignalKind

§

impl UnwindSafe for rustmax::tokio::sync::oneshot::error::RecvError

§

impl UnwindSafe for AcquireError

§

impl UnwindSafe for rustmax::tokio::sync::BarrierWaitResult

§

impl UnwindSafe for rustmax::tokio::sync::TryLockError

§

impl UnwindSafe for rustmax::tokio::sync::watch::error::RecvError

§

impl UnwindSafe for rustmax::tokio::task::Id

§

impl UnwindSafe for rustmax::tokio::time::error::Elapsed

§

impl UnwindSafe for rustmax::tokio::time::error::Error

§

impl UnwindSafe for Duration

§

impl UnwindSafe for rustmax::tokio::time::Instant

§

impl UnwindSafe for rustmax::toml::de::Error

§

impl UnwindSafe for rustmax::toml::ser::Buffer

§

impl UnwindSafe for rustmax::toml::ser::Error

§

impl UnwindSafe for rustmax::toml::value::Date

§

impl UnwindSafe for Datetime

§

impl UnwindSafe for DatetimeParseError

§

impl UnwindSafe for rustmax::toml::value::Time

§

impl UnwindSafe for Closed

§

impl UnwindSafe for rustmax::tower::layer::util::Identity

§

impl UnwindSafe for Rate

§

impl UnwindSafe for ConcurrencyLimitLayer

§

impl UnwindSafe for RateLimitLayer

§

impl UnwindSafe for Cost

§

impl UnwindSafe for rustmax::tower::load::peak_ewma::Handle

§

impl UnwindSafe for rustmax::tower::load::pending_requests::Count

§

impl UnwindSafe for rustmax::tower::load::pending_requests::Handle

§

impl UnwindSafe for CompleteOnResponse

§

impl UnwindSafe for Overloaded

§

impl UnwindSafe for LoadShedLayer

§

impl UnwindSafe for InvalidBackoff

§

impl UnwindSafe for TpsBudget

§

impl UnwindSafe for SpawnReadyLayer

§

impl UnwindSafe for rustmax::tower::timeout::error::Elapsed

§

impl UnwindSafe for TimeoutLayer

§

impl UnwindSafe for None

§

impl UnwindSafe for GraphemeCursor

§

impl UnwindSafe for OpaqueOrigin

§

impl UnwindSafe for rustmax::walkdir::DirEntry

§

impl UnwindSafe for rustmax::xshell::TempDir

§

impl UnwindSafe for __c_anonymous_ifc_ifcu

§

impl UnwindSafe for __c_anonymous_ifr_ifru

§

impl UnwindSafe for __c_anonymous_iwreq

§

impl UnwindSafe for __c_anonymous_ptp_perout_request_1

§

impl UnwindSafe for __c_anonymous_ptp_perout_request_2

§

impl UnwindSafe for __c_anonymous_ptrace_syscall_info_data

§

impl UnwindSafe for __c_anonymous_sockaddr_can_can_addr

§

impl UnwindSafe for __c_anonymous_xsk_tx_metadata_union

§

impl UnwindSafe for iwreq_data

§

impl UnwindSafe for tpacket_bd_header_u

§

impl UnwindSafe for tpacket_req_u

§

impl UnwindSafe for Big8x3

§

impl UnwindSafe for Big32x40

§

impl UnwindSafe for Decimal

§

impl UnwindSafe for DecimalSeq

§

impl UnwindSafe for Decoded

§

impl UnwindSafe for FullDecoded

§

impl UnwindSafe for I32NotAllOnes

§

impl UnwindSafe for I64NotAllOnes

§

impl UnwindSafe for InvertedUTerm

§

impl UnwindSafe for LitKind

§

impl UnwindSafe for MustAbort

§

impl UnwindSafe for Nanoseconds

§

impl UnwindSafe for NonZeroI8Inner

§

impl UnwindSafe for NonZeroI16Inner

§

impl UnwindSafe for NonZeroI32Inner

§

impl UnwindSafe for NonZeroI64Inner

§

impl UnwindSafe for NonZeroI128Inner

§

impl UnwindSafe for NonZeroIsizeInner

§

impl UnwindSafe for NonZeroU8Inner

§

impl UnwindSafe for NonZeroU16Inner

§

impl UnwindSafe for NonZeroU32Inner

§

impl UnwindSafe for NonZeroU64Inner

§

impl UnwindSafe for NonZeroU128Inner

§

impl UnwindSafe for NonZeroUsizeInner

§

impl UnwindSafe for PanicMessage

§

impl UnwindSafe for ProcMacro

§

impl UnwindSafe for SameThread

§

impl UnwindSafe for Sign

§

impl UnwindSafe for TryCaptureWithDebug

§

impl UnwindSafe for TryCaptureWithoutDebug

§

impl UnwindSafe for U32NotAllOnes

§

impl UnwindSafe for U64NotAllOnes

§

impl UnwindSafe for UsizeNoHighBit

§

impl<'a> !UnwindSafe for rustmax::serde_json::map::Entry<'a>

§

impl<'a> !UnwindSafe for rustmax::anyhow::Chain<'a>

§

impl<'a> !UnwindSafe for rustmax::core::error::Request<'a>

§

impl<'a> !UnwindSafe for Source<'a>

§

impl<'a> !UnwindSafe for rustmax::core::fmt::Formatter<'a>

§

impl<'a> !UnwindSafe for BorrowedCursor<'a>

§

impl<'a> !UnwindSafe for ContextBuilder<'a>

§

impl<'a> !UnwindSafe for rustmax::crossbeam::channel::Select<'a>

§

impl<'a> !UnwindSafe for IoSliceMut<'a>

§

impl<'a> !UnwindSafe for rustmax::hyper::rt::ReadBuf<'a>

§

impl<'a> !UnwindSafe for ReadBufCursor<'a>

§

impl<'a> !UnwindSafe for ResultCacheKey<'a>

§

impl<'a> !UnwindSafe for rustmax::rayon::string::Drain<'a>

§

impl<'a> !UnwindSafe for BroadcastContext<'a>

§

impl<'a> !UnwindSafe for rustmax::serde_json::map::IterMut<'a>

§

impl<'a> !UnwindSafe for rustmax::serde_json::map::OccupiedEntry<'a>

§

impl<'a> !UnwindSafe for rustmax::serde_json::map::VacantEntry<'a>

§

impl<'a> !UnwindSafe for rustmax::serde_json::map::ValuesMut<'a>

§

impl<'a> !UnwindSafe for MaybeUninitSlice<'a>

§

impl<'a> !UnwindSafe for SocketAncillary<'a>

§

impl<'a> !UnwindSafe for PanicHookInfo<'a>

§

impl<'a> !UnwindSafe for rustmax::tokio::io::ReadBuf<'a>

§

impl<'a> !UnwindSafe for EnterGuard<'a>

§

impl<'a> !UnwindSafe for Notified<'a>

§

impl<'a> !UnwindSafe for SemaphorePermit<'a>

§

impl<'a> !UnwindSafe for ParseOptions<'a>

§

impl<'a> !UnwindSafe for PathSegmentsMut<'a>

§

impl<'a> !UnwindSafe for UrlQuery<'a>

§

impl<'a> UnwindSafe for BytesOrWideString<'a>

§

impl<'a> UnwindSafe for rustmax::chrono::format::Item<'a>

§

impl<'a> UnwindSafe for Utf8Pattern<'a>

§

impl<'a> UnwindSafe for IndexVecIter<'a>

§

impl<'a> UnwindSafe for Unexpected<'a>

§

impl<'a> UnwindSafe for AncillaryData<'a>

§

impl<'a> UnwindSafe for Component<'a>

§

impl<'a> UnwindSafe for Prefix<'a>

§

impl<'a> UnwindSafe for rustmax::alloc::string::Drain<'a>

§

impl<'a> UnwindSafe for RawPathParamsIter<'a>

§

impl<'a> UnwindSafe for SymbolName<'a>

§

impl<'a> UnwindSafe for AttributeInfo<'a>

§

impl<'a> UnwindSafe for DeriveInfo<'a>

§

impl<'a> UnwindSafe for FieldInfo<'a>

§

impl<'a> UnwindSafe for ItemInfo<'a>

§

impl<'a> UnwindSafe for StrftimeItems<'a>

§

impl<'a> UnwindSafe for IdsRef<'a>

§

impl<'a> UnwindSafe for Indices<'a>

§

impl<'a> UnwindSafe for RawValues<'a>

§

impl<'a> UnwindSafe for rustmax::core::ffi::c_str::Bytes<'a>

§

impl<'a> UnwindSafe for Arguments<'a>

§

impl<'a> UnwindSafe for PhantomContravariantLifetime<'a>

§

impl<'a> UnwindSafe for PhantomCovariantLifetime<'a>

§

impl<'a> UnwindSafe for PhantomInvariantLifetime<'a>

§

impl<'a> UnwindSafe for rustmax::core::panic::Location<'a>

§

impl<'a> UnwindSafe for PanicInfo<'a>

§

impl<'a> UnwindSafe for rustmax::core::panic::PanicMessage<'a>

§

impl<'a> UnwindSafe for EscapeAscii<'a>

§

impl<'a> UnwindSafe for CharSearcher<'a>

§

impl<'a> UnwindSafe for rustmax::core::str::Bytes<'a>

§

impl<'a> UnwindSafe for rustmax::core::str::CharIndices<'a>

§

impl<'a> UnwindSafe for rustmax::core::str::Chars<'a>

§

impl<'a> UnwindSafe for rustmax::core::str::EncodeUtf16<'a>

§

impl<'a> UnwindSafe for rustmax::core::str::EscapeDebug<'a>

§

impl<'a> UnwindSafe for rustmax::core::str::EscapeDefault<'a>

§

impl<'a> UnwindSafe for rustmax::core::str::EscapeUnicode<'a>

§

impl<'a> UnwindSafe for rustmax::core::str::Lines<'a>

§

impl<'a> UnwindSafe for LinesAny<'a>

§

impl<'a> UnwindSafe for rustmax::core::str::SplitAsciiWhitespace<'a>

§

impl<'a> UnwindSafe for rustmax::core::str::SplitWhitespace<'a>

§

impl<'a> UnwindSafe for Utf8Chunk<'a>

§

impl<'a> UnwindSafe for Utf8Chunks<'a>

§

impl<'a> UnwindSafe for SelectedOperation<'a>

§

impl<'a> UnwindSafe for Env<'a>

§

impl<'a> UnwindSafe for IoSlice<'a>

§

impl<'a> UnwindSafe for rustmax::futures::task::Context<'a>

§

impl<'a> UnwindSafe for WakerRef<'a>

§

impl<'a> UnwindSafe for SpanArithmetic<'a>

§

impl<'a> UnwindSafe for SpanCompare<'a>

§

impl<'a> UnwindSafe for SpanRelativeTo<'a>

§

impl<'a> UnwindSafe for SpanRound<'a>

§

impl<'a> UnwindSafe for SpanTotal<'a>

§

impl<'a> UnwindSafe for ZonedDifference<'a>

§

impl<'a> UnwindSafe for rustmax::log::Metadata<'a>

§

impl<'a> UnwindSafe for MetadataBuilder<'a>

§

impl<'a> UnwindSafe for Record<'a>

§

impl<'a> UnwindSafe for RecordBuilder<'a>

§

impl<'a> UnwindSafe for MimeIter<'a>

§

impl<'a> UnwindSafe for rustmax::mime::Name<'a>

§

impl<'a> UnwindSafe for Params<'a>

§

impl<'a> UnwindSafe for U32Digits<'a>

§

impl<'a> UnwindSafe for U64Digits<'a>

§

impl<'a> UnwindSafe for CharStrategy<'a>

§

impl<'a> UnwindSafe for rustmax::regex::bytes::SetMatchesIter<'a>

§

impl<'a> UnwindSafe for rustmax::regex::SetMatchesIter<'a>

§

impl<'a> UnwindSafe for Attempt<'a>

§

impl<'a> UnwindSafe for SearchResult<'a>

§

impl<'a> UnwindSafe for SliceRead<'a>

§

impl<'a> UnwindSafe for StrRead<'a>

§

impl<'a> UnwindSafe for rustmax::serde_json::map::Iter<'a>

§

impl<'a> UnwindSafe for rustmax::serde_json::map::Keys<'a>

§

impl<'a> UnwindSafe for rustmax::serde_json::map::Values<'a>

§

impl<'a> UnwindSafe for PrettyFormatter<'a>

§

impl<'a> UnwindSafe for SplitPaths<'a>

§

impl<'a> UnwindSafe for rustmax::std::ffi::os_str::Display<'a>

§

impl<'a> UnwindSafe for StdinLock<'a>

§

impl<'a> UnwindSafe for rustmax::std::net::Incoming<'a>

§

impl<'a> UnwindSafe for rustmax::std::os::unix::net::Incoming<'a>

§

impl<'a> UnwindSafe for Messages<'a>

§

impl<'a> UnwindSafe for ScmCredentials<'a>

§

impl<'a> UnwindSafe for ScmRights<'a>

§

impl<'a> UnwindSafe for Ancestors<'a>

§

impl<'a> UnwindSafe for Components<'a>

§

impl<'a> UnwindSafe for rustmax::std::path::Display<'a>

§

impl<'a> UnwindSafe for rustmax::std::path::Iter<'a>

§

impl<'a> UnwindSafe for PrefixComponent<'a>

§

impl<'a> UnwindSafe for CommandArgs<'a>

§

impl<'a> UnwindSafe for CommandEnvs<'a>

§

impl<'a> UnwindSafe for rustmax::syn::buffer::Cursor<'a>

§

impl<'a> UnwindSafe for ParseNestedMeta<'a>

§

impl<'a> UnwindSafe for Lookahead1<'a>

§

impl<'a> UnwindSafe for ImplGenerics<'a>

§

impl<'a> UnwindSafe for Turbofish<'a>

§

impl<'a> UnwindSafe for TypeGenerics<'a>

§

impl<'a> UnwindSafe for HyperlinkSpec<'a>

§

impl<'a> UnwindSafe for StandardStreamLock<'a>

§

impl<'a> UnwindSafe for rustmax::tokio::net::tcp::ReadHalf<'a>

§

impl<'a> UnwindSafe for rustmax::tokio::net::tcp::WriteHalf<'a>

§

impl<'a> UnwindSafe for rustmax::tokio::net::unix::ReadHalf<'a>

§

impl<'a> UnwindSafe for rustmax::tokio::net::unix::WriteHalf<'a>

§

impl<'a> UnwindSafe for GraphemeIndices<'a>

§

impl<'a> UnwindSafe for Graphemes<'a>

§

impl<'a> UnwindSafe for USentenceBoundIndices<'a>

§

impl<'a> UnwindSafe for USentenceBounds<'a>

§

impl<'a> UnwindSafe for UWordBoundIndices<'a>

§

impl<'a> UnwindSafe for UWordBounds<'a>

§

impl<'a> UnwindSafe for UnicodeSentences<'a>

§

impl<'a> UnwindSafe for UnicodeWordIndices<'a>

§

impl<'a> UnwindSafe for UnicodeWords<'a>

§

impl<'a> UnwindSafe for ByteSerialize<'a>

§

impl<'a> UnwindSafe for Parse<'a>

§

impl<'a> UnwindSafe for ParseIntoOwned<'a>

§

impl<'a> UnwindSafe for rustmax::xshell::Cmd<'a>

§

impl<'a> UnwindSafe for PushDir<'a>

§

impl<'a> UnwindSafe for PushEnv<'a>

§

impl<'a> UnwindSafe for BridgeConfig<'a>

§

impl<'a> UnwindSafe for Formatted<'a>

§

impl<'a> UnwindSafe for Part<'a>

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<'a, 'b> UnwindSafe for rustmax::tempfile::Builder<'a, 'b>

§

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

§

impl<'a, 'e, E> UnwindSafe for Base64Display<'a, 'e, E>
where E: RefUnwindSafe,

§

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

§

impl<'a, A> !UnwindSafe for rustmax::core::option::IterMut<'a, A>

§

impl<'a, A> UnwindSafe for rustmax::core::option::Iter<'a, A>
where A: RefUnwindSafe,

§

impl<'a, B> UnwindSafe for Cow<'a, B>
where <B as ToOwned>::Owned: UnwindSafe, B: RefUnwindSafe + ?Sized,

§

impl<'a, B, S = ()> !UnwindSafe for RouterAsService<'a, B, S>

§

impl<'a, E> UnwindSafe for BytesDeserializer<'a, E>
where E: UnwindSafe,

§

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

§

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

§

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

§

impl<'a, F, O> !UnwindSafe for Fill<'a, F, O>

§

impl<'a, Fut> !UnwindSafe for rustmax::prelude::stream::futures_unordered::Iter<'a, Fut>

§

impl<'a, Fut> !UnwindSafe for rustmax::prelude::stream::futures_unordered::IterMut<'a, Fut>

§

impl<'a, Fut> !UnwindSafe for IterPinMut<'a, Fut>

§

impl<'a, Fut> !UnwindSafe for IterPinRef<'a, Fut>

§

impl<'a, I> !UnwindSafe for ByRefSized<'a, I>

§

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

§

impl<'a, I> !UnwindSafe for rustmax::itertools::Chunks<'a, I>

§

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

§

impl<'a, I, A> UnwindSafe for Splice<'a, I, A>

§

impl<'a, I, E> !UnwindSafe for ProcessResults<'a, I, E>

§

impl<'a, I, F> !UnwindSafe for PeekingTakeWhile<'a, I, F>

§

impl<'a, I, F> !UnwindSafe for TakeWhileRef<'a, I, F>

§

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

§

impl<'a, K> UnwindSafe for rustmax::alloc::collections::btree_set::Cursor<'a, K>
where K: RefUnwindSafe,

§

impl<'a, K> UnwindSafe for rustmax::std::collections::hash_set::Drain<'a, K>
where K: RefUnwindSafe,

§

impl<'a, K> UnwindSafe for rustmax::std::collections::hash_set::Iter<'a, K>
where K: RefUnwindSafe,

§

impl<'a, K, A = Global> !UnwindSafe for rustmax::alloc::collections::btree_set::CursorMut<'a, K, A>

§

impl<'a, K, A = Global> !UnwindSafe for rustmax::alloc::collections::btree_set::CursorMutKey<'a, K, A>

§

impl<'a, K, F> !UnwindSafe for rustmax::std::collections::hash_set::ExtractIf<'a, K, F>

§

impl<'a, K, I, F> !UnwindSafe for rustmax::itertools::Group<'a, K, I, F>

§

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

§

impl<'a, K, V> !UnwindSafe for rustmax::std::collections::hash_map::Entry<'a, K, V>

§

impl<'a, K, V> !UnwindSafe for rustmax::toml::map::Entry<'a, K, V>

§

impl<'a, K, V> !UnwindSafe for rustmax::alloc::collections::btree_map::IterMut<'a, K, V>

§

impl<'a, K, V> !UnwindSafe for RangeMut<'a, K, V>

§

impl<'a, K, V> !UnwindSafe for rustmax::alloc::collections::btree_map::ValuesMut<'a, K, V>

§

impl<'a, K, V> !UnwindSafe for rustmax::rayon::collections::btree_map::IterMut<'a, K, V>

§

impl<'a, K, V> !UnwindSafe for rustmax::rayon::collections::hash_map::Drain<'a, K, V>

§

impl<'a, K, V> !UnwindSafe for rustmax::rayon::collections::hash_map::IterMut<'a, K, V>

§

impl<'a, K, V> !UnwindSafe for rustmax::std::collections::hash_map::IterMut<'a, K, V>

§

impl<'a, K, V> !UnwindSafe for rustmax::std::collections::hash_map::OccupiedEntry<'a, K, V>

§

impl<'a, K, V> !UnwindSafe for rustmax::std::collections::hash_map::OccupiedError<'a, K, V>

§

impl<'a, K, V> !UnwindSafe for rustmax::std::collections::hash_map::VacantEntry<'a, K, V>

§

impl<'a, K, V> !UnwindSafe for rustmax::std::collections::hash_map::ValuesMut<'a, K, V>

§

impl<'a, K, V> !UnwindSafe for rustmax::toml::map::IterMut<'a, K, V>

§

impl<'a, K, V> !UnwindSafe for rustmax::toml::map::OccupiedEntry<'a, K, V>

§

impl<'a, K, V> !UnwindSafe for rustmax::toml::map::VacantEntry<'a, K, V>

§

impl<'a, K, V> UnwindSafe for rustmax::alloc::collections::btree_map::Cursor<'a, K, V>

§

impl<'a, K, V> UnwindSafe for rustmax::alloc::collections::btree_map::Iter<'a, K, V>

§

impl<'a, K, V> UnwindSafe for rustmax::alloc::collections::btree_map::Keys<'a, K, V>

§

impl<'a, K, V> UnwindSafe for rustmax::alloc::collections::btree_map::Range<'a, K, V>

§

impl<'a, K, V> UnwindSafe for rustmax::alloc::collections::btree_map::Values<'a, K, V>

§

impl<'a, K, V> UnwindSafe for rustmax::rayon::collections::btree_map::Iter<'a, K, V>

§

impl<'a, K, V> UnwindSafe for rustmax::rayon::collections::hash_map::Iter<'a, K, V>

§

impl<'a, K, V> UnwindSafe for rustmax::std::collections::hash_map::Drain<'a, K, V>

§

impl<'a, K, V> UnwindSafe for rustmax::std::collections::hash_map::Iter<'a, K, V>

§

impl<'a, K, V> UnwindSafe for rustmax::std::collections::hash_map::Keys<'a, K, V>

§

impl<'a, K, V> UnwindSafe for rustmax::std::collections::hash_map::Values<'a, K, V>

§

impl<'a, K, V> UnwindSafe for rustmax::toml::map::Iter<'a, K, V>

§

impl<'a, K, V> UnwindSafe for rustmax::toml::map::Keys<'a, K, V>

§

impl<'a, K, V> UnwindSafe for rustmax::toml::map::Values<'a, K, V>

§

impl<'a, K, V, A = Global> !UnwindSafe for rustmax::alloc::collections::btree_map::Entry<'a, K, V, A>

§

impl<'a, K, V, A = Global> !UnwindSafe for rustmax::alloc::collections::btree_map::CursorMut<'a, K, V, A>

§

impl<'a, K, V, A = Global> !UnwindSafe for rustmax::alloc::collections::btree_map::CursorMutKey<'a, K, V, A>

§

impl<'a, K, V, A = Global> !UnwindSafe for rustmax::alloc::collections::btree_map::OccupiedEntry<'a, K, V, A>

§

impl<'a, K, V, A = Global> !UnwindSafe for rustmax::alloc::collections::btree_map::OccupiedError<'a, K, V, A>

§

impl<'a, K, V, A = Global> !UnwindSafe for rustmax::alloc::collections::btree_map::VacantEntry<'a, K, V, A>

§

impl<'a, K, V, F> !UnwindSafe for rustmax::std::collections::hash_map::ExtractIf<'a, K, V, F>

§

impl<'a, K, V, F, A = Global> !UnwindSafe for rustmax::alloc::collections::btree_map::ExtractIf<'a, K, V, F, A>

§

impl<'a, L> UnwindSafe for IncomingStream<'a, L>
where <L as Listener>::Addr: UnwindSafe, <L as Listener>::Io: RefUnwindSafe,

§

impl<'a, M, Request> !UnwindSafe for AsService<'a, M, Request>

§

impl<'a, P> UnwindSafe for rustmax::core::str::MatchIndices<'a, P>
where <P as Pattern>::Searcher<'a>: UnwindSafe,

§

impl<'a, P> UnwindSafe for rustmax::core::str::Matches<'a, P>
where <P as Pattern>::Searcher<'a>: UnwindSafe,

§

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

§

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

§

impl<'a, P> UnwindSafe for rustmax::core::str::RSplit<'a, P>
where <P as Pattern>::Searcher<'a>: UnwindSafe,

§

impl<'a, P> UnwindSafe for rustmax::core::str::RSplitN<'a, P>
where <P as Pattern>::Searcher<'a>: UnwindSafe,

§

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

§

impl<'a, P> UnwindSafe for rustmax::core::str::Split<'a, P>
where <P as Pattern>::Searcher<'a>: UnwindSafe,

§

impl<'a, P> UnwindSafe for rustmax::core::str::SplitInclusive<'a, P>
where <P as Pattern>::Searcher<'a>: UnwindSafe,

§

impl<'a, P> UnwindSafe for rustmax::core::str::SplitN<'a, P>
where <P as Pattern>::Searcher<'a>: UnwindSafe,

§

impl<'a, P> UnwindSafe for rustmax::core::str::SplitTerminator<'a, P>
where <P as Pattern>::Searcher<'a>: UnwindSafe,

§

impl<'a, R> !UnwindSafe for FillBuf<'a, R>

§

impl<'a, R> !UnwindSafe for Read<'a, R>

§

impl<'a, R> !UnwindSafe for ReadExact<'a, R>

§

impl<'a, R> !UnwindSafe for ReadLine<'a, R>

§

impl<'a, R> !UnwindSafe for ReadToEnd<'a, R>

§

impl<'a, R> !UnwindSafe for ReadToString<'a, R>

§

impl<'a, R> !UnwindSafe for ReadUntil<'a, R>

§

impl<'a, R> !UnwindSafe for ReadVectored<'a, R>

§

impl<'a, R> !UnwindSafe for SeeKRelative<'a, R>

§

impl<'a, R> !UnwindSafe for RngReadAdapter<'a, R>

§

impl<'a, R> !UnwindSafe for rustmax::regex::bytes::ReplacerRef<'a, R>

§

impl<'a, R> !UnwindSafe for rustmax::regex::ReplacerRef<'a, R>

§

impl<'a, R, W> !UnwindSafe for Copy<'a, R, W>

§

impl<'a, R, W> !UnwindSafe for CopyBuf<'a, R, W>

§

impl<'a, R, W> !UnwindSafe for CopyBufAbortable<'a, R, W>

§

impl<'a, S> !UnwindSafe for Seek<'a, S>

§

impl<'a, S, T> UnwindSafe for SliceChooseIter<'a, S, T>
where S: RefUnwindSafe + ?Sized, T: UnwindSafe,

§

impl<'a, Si, Item> !UnwindSafe for rustmax::prelude::sink::Close<'a, Si, Item>

§

impl<'a, Si, Item> !UnwindSafe for Feed<'a, Si, Item>

§

impl<'a, Si, Item> !UnwindSafe for rustmax::prelude::sink::Flush<'a, Si, Item>

§

impl<'a, Si, Item> !UnwindSafe for Send<'a, Si, Item>

§

impl<'a, Si, St> !UnwindSafe for SendAll<'a, Si, St>

§

impl<'a, St> !UnwindSafe for rustmax::prelude::stream::select_all::Iter<'a, St>

§

impl<'a, St> !UnwindSafe for rustmax::prelude::stream::select_all::IterMut<'a, St>

§

impl<'a, St> !UnwindSafe for rustmax::prelude::stream::Next<'a, St>

§

impl<'a, St> !UnwindSafe for rustmax::prelude::stream::Peek<'a, St>

§

impl<'a, St> !UnwindSafe for rustmax::prelude::stream::PeekMut<'a, St>

§

impl<'a, St> !UnwindSafe for SelectNextSome<'a, St>

§

impl<'a, St> !UnwindSafe for TryNext<'a, St>

§

impl<'a, St, F> !UnwindSafe for NextIf<'a, St, F>

§

impl<'a, St, T> !UnwindSafe for NextIfEq<'a, St, T>

§

impl<'a, T> !UnwindSafe for rustmax::http::header::Entry<'a, T>

§

impl<'a, T> !UnwindSafe for rustmax::alloc::collections::linked_list::IterMut<'a, T>

§

impl<'a, T> !UnwindSafe for rustmax::alloc::collections::vec_deque::IterMut<'a, T>

§

impl<'a, T> !UnwindSafe for ValuesRef<'a, T>

§

impl<'a, T> !UnwindSafe for rustmax::core::result::IterMut<'a, T>

§

impl<'a, T> !UnwindSafe for rustmax::core::slice::ChunksExactMut<'a, T>

§

impl<'a, T> !UnwindSafe for rustmax::core::slice::ChunksMut<'a, T>

§

impl<'a, T> !UnwindSafe for rustmax::core::slice::IterMut<'a, T>

§

impl<'a, T> !UnwindSafe for rustmax::core::slice::RChunksExactMut<'a, T>

§

impl<'a, T> !UnwindSafe for rustmax::core::slice::RChunksMut<'a, T>

§

impl<'a, T> !UnwindSafe for rustmax::cxx::vector::IterMut<'a, T>

§

impl<'a, T> !UnwindSafe for Cancellation<'a, T>

§

impl<'a, T> !UnwindSafe for rustmax::futures::lock::MutexGuard<'a, T>

§

impl<'a, T> !UnwindSafe for MutexLockFuture<'a, T>

§

impl<'a, T> !UnwindSafe for rustmax::http::header::Drain<'a, T>

§

impl<'a, T> !UnwindSafe for rustmax::http::header::IterMut<'a, T>

§

impl<'a, T> !UnwindSafe for rustmax::http::header::OccupiedEntry<'a, T>

§

impl<'a, T> !UnwindSafe for rustmax::http::header::VacantEntry<'a, T>

§

impl<'a, T> !UnwindSafe for ValueDrain<'a, T>

§

impl<'a, T> !UnwindSafe for ValueIterMut<'a, T>

§

impl<'a, T> !UnwindSafe for rustmax::http::header::ValuesMut<'a, T>

§

impl<'a, T> !UnwindSafe for FutureObj<'a, T>

§

impl<'a, T> !UnwindSafe for LocalFutureObj<'a, T>

§

impl<'a, T> !UnwindSafe for rustmax::rayon::collections::binary_heap::Drain<'a, T>

§

impl<'a, T> !UnwindSafe for rustmax::rayon::collections::hash_set::Drain<'a, T>

§

impl<'a, T> !UnwindSafe for rustmax::rayon::collections::linked_list::IterMut<'a, T>

§

impl<'a, T> !UnwindSafe for rustmax::rayon::collections::vec_deque::Drain<'a, T>

§

impl<'a, T> !UnwindSafe for rustmax::rayon::collections::vec_deque::IterMut<'a, T>

§

impl<'a, T> !UnwindSafe for rustmax::rayon::option::IterMut<'a, T>

§

impl<'a, T> !UnwindSafe for rustmax::rayon::result::IterMut<'a, T>

§

impl<'a, T> !UnwindSafe for rustmax::std::sync::MappedMutexGuard<'a, T>

§

impl<'a, T> !UnwindSafe for MappedRwLockWriteGuard<'a, T>

§

impl<'a, T> !UnwindSafe for rustmax::syn::punctuated::Iter<'a, T>

§

impl<'a, T> !UnwindSafe for rustmax::syn::punctuated::IterMut<'a, T>

§

impl<'a, T> !UnwindSafe for AsyncFdReadyGuard<'a, T>

§

impl<'a, T> !UnwindSafe for AsyncFdReadyMutGuard<'a, T>

§

impl<'a, T> !UnwindSafe for rustmax::tokio::sync::MappedMutexGuard<'a, T>

§

impl<'a, T> !UnwindSafe for rustmax::tokio::sync::MutexGuard<'a, T>

§

impl<'a, T> !UnwindSafe for RwLockMappedWriteGuard<'a, T>

§

impl<'a, T> !UnwindSafe for rustmax::tokio::sync::RwLockReadGuard<'a, T>

§

impl<'a, T> !UnwindSafe for rustmax::tokio::sync::RwLockWriteGuard<'a, T>

§

impl<'a, T> !UnwindSafe for rustmax::tokio::sync::watch::Ref<'a, T>

§

impl<'a, T> !UnwindSafe for rustmax::url::form_urlencoded::Serializer<'a, T>

§

impl<'a, T> UnwindSafe for rustmax::alloc::collections::binary_heap::Iter<'a, T>
where T: RefUnwindSafe,

§

impl<'a, T> UnwindSafe for rustmax::alloc::collections::btree_set::Iter<'a, T>
where T: RefUnwindSafe,

§

impl<'a, T> UnwindSafe for rustmax::alloc::collections::btree_set::Range<'a, T>
where T: RefUnwindSafe,

§

impl<'a, T> UnwindSafe for rustmax::alloc::collections::btree_set::SymmetricDifference<'a, T>
where T: RefUnwindSafe,

§

impl<'a, T> UnwindSafe for rustmax::alloc::collections::btree_set::Union<'a, T>
where T: RefUnwindSafe,

§

impl<'a, T> UnwindSafe for rustmax::alloc::collections::linked_list::Iter<'a, T>
where T: RefUnwindSafe,

§

impl<'a, T> UnwindSafe for rustmax::alloc::collections::vec_deque::Iter<'a, T>
where T: RefUnwindSafe,

§

impl<'a, T> UnwindSafe for rustmax::core::result::Iter<'a, T>
where T: RefUnwindSafe,

§

impl<'a, T> UnwindSafe for rustmax::core::slice::Chunks<'a, T>
where T: RefUnwindSafe,

§

impl<'a, T> UnwindSafe for rustmax::core::slice::ChunksExact<'a, T>
where T: RefUnwindSafe,

§

impl<'a, T> UnwindSafe for rustmax::core::slice::Iter<'a, T>
where T: RefUnwindSafe,

§

impl<'a, T> UnwindSafe for rustmax::core::slice::RChunks<'a, T>
where T: RefUnwindSafe,

§

impl<'a, T> UnwindSafe for rustmax::core::slice::RChunksExact<'a, T>
where T: RefUnwindSafe,

§

impl<'a, T> UnwindSafe for rustmax::core::slice::Windows<'a, T>
where T: RefUnwindSafe,

§

impl<'a, T> UnwindSafe for rustmax::crossbeam::channel::Iter<'a, T>

§

impl<'a, T> UnwindSafe for rustmax::crossbeam::channel::TryIter<'a, T>

§

impl<'a, T> UnwindSafe for ShardedLockReadGuard<'a, T>
where T: RefUnwindSafe + ?Sized,

§

impl<'a, T> UnwindSafe for ShardedLockWriteGuard<'a, T>
where T: ?Sized,

§

impl<'a, T> UnwindSafe for rustmax::cxx::vector::Iter<'a, T>
where T: RefUnwindSafe,

§

impl<'a, T> UnwindSafe for GetAll<'a, T>
where T: RefUnwindSafe,

§

impl<'a, T> UnwindSafe for rustmax::http::header::Iter<'a, T>
where T: RefUnwindSafe,

§

impl<'a, T> UnwindSafe for rustmax::http::header::Keys<'a, T>
where T: RefUnwindSafe,

§

impl<'a, T> UnwindSafe for ValueIter<'a, T>
where T: RefUnwindSafe,

§

impl<'a, T> UnwindSafe for rustmax::http::header::Values<'a, T>
where T: RefUnwindSafe,

§

impl<'a, T> UnwindSafe for Choose<'a, T>
where T: RefUnwindSafe,

§

impl<'a, T> UnwindSafe for rustmax::rayon::collections::binary_heap::Iter<'a, T>
where T: RefUnwindSafe,

§

impl<'a, T> UnwindSafe for rustmax::rayon::collections::btree_set::Iter<'a, T>
where T: RefUnwindSafe,

§

impl<'a, T> UnwindSafe for rustmax::rayon::collections::hash_set::Iter<'a, T>
where T: RefUnwindSafe,

§

impl<'a, T> UnwindSafe for rustmax::rayon::collections::linked_list::Iter<'a, T>
where T: RefUnwindSafe,

§

impl<'a, T> UnwindSafe for rustmax::rayon::collections::vec_deque::Iter<'a, T>
where T: RefUnwindSafe,

§

impl<'a, T> UnwindSafe for rustmax::rayon::option::Iter<'a, T>
where T: RefUnwindSafe,

§

impl<'a, T> UnwindSafe for rustmax::rayon::result::Iter<'a, T>
where T: RefUnwindSafe,

§

impl<'a, T> UnwindSafe for rustmax::std::sync::mpmc::Iter<'a, T>

§

impl<'a, T> UnwindSafe for rustmax::std::sync::mpmc::TryIter<'a, T>

§

impl<'a, T> UnwindSafe for rustmax::std::sync::mpsc::Iter<'a, T>

§

impl<'a, T> UnwindSafe for rustmax::std::sync::mpsc::TryIter<'a, T>

§

impl<'a, T> UnwindSafe for MappedRwLockReadGuard<'a, T>
where T: RefUnwindSafe + ?Sized,

§

impl<'a, T> UnwindSafe for rustmax::std::sync::MutexGuard<'a, T>
where T: ?Sized,

§

impl<'a, T> UnwindSafe for ReentrantLockGuard<'a, T>
where T: RefUnwindSafe + ?Sized,

§

impl<'a, T> UnwindSafe for rustmax::std::sync::RwLockReadGuard<'a, T>
where T: RefUnwindSafe + ?Sized,

§

impl<'a, T> UnwindSafe for rustmax::std::sync::RwLockWriteGuard<'a, T>
where T: ?Sized,

§

impl<'a, T> UnwindSafe for Permit<'a, T>

§

impl<'a, T> UnwindSafe for PermitIterator<'a, T>

§

impl<'a, T, A = Global> !UnwindSafe for rustmax::alloc::collections::btree_set::Entry<'a, T, A>

§

impl<'a, T, A = Global> !UnwindSafe for DrainSorted<'a, T, A>

§

impl<'a, T, A = Global> !UnwindSafe for rustmax::alloc::collections::binary_heap::PeekMut<'a, T, A>

§

impl<'a, T, A = Global> !UnwindSafe for rustmax::alloc::collections::btree_set::OccupiedEntry<'a, T, A>

§

impl<'a, T, A = Global> !UnwindSafe for rustmax::alloc::collections::btree_set::VacantEntry<'a, T, A>

§

impl<'a, T, A = Global> !UnwindSafe for rustmax::alloc::collections::linked_list::CursorMut<'a, T, A>

§

impl<'a, T, A> UnwindSafe for rustmax::alloc::collections::binary_heap::Drain<'a, T, A>

§

impl<'a, T, A> UnwindSafe for rustmax::alloc::collections::btree_set::Difference<'a, T, A>

§

impl<'a, T, A> UnwindSafe for rustmax::alloc::collections::btree_set::Intersection<'a, T, A>

§

impl<'a, T, A> UnwindSafe for rustmax::alloc::collections::linked_list::Cursor<'a, T, A>

§

impl<'a, T, A> UnwindSafe for rustmax::alloc::collections::vec_deque::Drain<'a, T, A>

§

impl<'a, T, A> UnwindSafe for rustmax::prelude::vec::Drain<'a, T, A>

§

impl<'a, T, F, A = Global> !UnwindSafe for rustmax::alloc::collections::btree_set::ExtractIf<'a, T, F, A>

§

impl<'a, T, F, A = Global> !UnwindSafe for rustmax::alloc::collections::linked_list::ExtractIf<'a, T, F, A>

§

impl<'a, T, F, A = Global> !UnwindSafe for rustmax::prelude::vec::ExtractIf<'a, T, F, A>

§

impl<'a, T, P> !UnwindSafe for rustmax::core::slice::ChunkByMut<'a, T, P>

§

impl<'a, T, P> !UnwindSafe for RSplitMut<'a, T, P>

§

impl<'a, T, P> !UnwindSafe for RSplitNMut<'a, T, P>

§

impl<'a, T, P> !UnwindSafe for rustmax::core::slice::SplitInclusiveMut<'a, T, P>

§

impl<'a, T, P> !UnwindSafe for rustmax::core::slice::SplitMut<'a, T, P>

§

impl<'a, T, P> !UnwindSafe for SplitNMut<'a, T, P>

§

impl<'a, T, P> !UnwindSafe for PairsMut<'a, T, P>

§

impl<'a, T, P> UnwindSafe for rustmax::core::slice::ChunkBy<'a, T, P>

§

impl<'a, T, P> UnwindSafe for rustmax::core::slice::RSplit<'a, T, P>

§

impl<'a, T, P> UnwindSafe for rustmax::core::slice::RSplitN<'a, T, P>

§

impl<'a, T, P> UnwindSafe for rustmax::core::slice::Split<'a, T, P>

§

impl<'a, T, P> UnwindSafe for rustmax::core::slice::SplitInclusive<'a, T, P>

§

impl<'a, T, P> UnwindSafe for rustmax::core::slice::SplitN<'a, T, P>

§

impl<'a, T, P> UnwindSafe for Pairs<'a, T, P>

§

impl<'a, T, Request> !UnwindSafe for rustmax::tower::util::Ready<'a, T, Request>

§

impl<'a, T, S> !UnwindSafe for rustmax::std::collections::hash_set::Entry<'a, T, S>

§

impl<'a, T, S> !UnwindSafe for rustmax::std::collections::hash_set::OccupiedEntry<'a, T, S>

§

impl<'a, T, S> !UnwindSafe for rustmax::std::collections::hash_set::VacantEntry<'a, T, S>

§

impl<'a, T, S> UnwindSafe for rustmax::std::collections::hash_set::Difference<'a, T, S>

§

impl<'a, T, S> UnwindSafe for rustmax::std::collections::hash_set::Intersection<'a, T, S>

§

impl<'a, T, S> UnwindSafe for rustmax::std::collections::hash_set::SymmetricDifference<'a, T, S>

§

impl<'a, T, S> UnwindSafe for rustmax::std::collections::hash_set::Union<'a, T, S>

§

impl<'a, T, U> !UnwindSafe for rustmax::futures::lock::MappedMutexGuard<'a, T, U>

§

impl<'a, T, const N: usize> !UnwindSafe for ArrayChunksMut<'a, T, N>

§

impl<'a, T, const N: usize> UnwindSafe for rustmax::core::slice::ArrayChunks<'a, T, N>
where T: RefUnwindSafe,

§

impl<'a, T, const N: usize> UnwindSafe for ArrayWindows<'a, T, N>
where T: RefUnwindSafe,

§

impl<'a, W> !UnwindSafe for rustmax::futures::io::Close<'a, W>

§

impl<'a, W> !UnwindSafe for rustmax::futures::io::Flush<'a, W>

§

impl<'a, W> !UnwindSafe for Write<'a, W>

§

impl<'a, W> !UnwindSafe for WriteAll<'a, W>

§

impl<'a, W> !UnwindSafe for WriteVectored<'a, W>

§

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

§

impl<'addr, 'bufs, 'control> !UnwindSafe for MsgHdrMut<'addr, 'bufs, 'control>

§

impl<'addr, 'bufs, 'control> UnwindSafe for MsgHdr<'addr, 'bufs, 'control>

§

impl<'b, T> !UnwindSafe for rustmax::core::cell::Ref<'b, T>

§

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

§

impl<'c, 'a> UnwindSafe for StepCursor<'c, 'a>

§

impl<'c, 'h> UnwindSafe for rustmax::regex::bytes::SubCaptureMatches<'c, 'h>

§

impl<'c, 'h> UnwindSafe for rustmax::regex::SubCaptureMatches<'c, 'h>

§

impl<'ch> UnwindSafe for rustmax::rayon::str::Bytes<'ch>

§

impl<'ch> UnwindSafe for rustmax::rayon::str::CharIndices<'ch>

§

impl<'ch> UnwindSafe for rustmax::rayon::str::Chars<'ch>

§

impl<'ch> UnwindSafe for rustmax::rayon::str::EncodeUtf16<'ch>

§

impl<'ch> UnwindSafe for rustmax::rayon::str::Lines<'ch>

§

impl<'ch> UnwindSafe for rustmax::rayon::str::SplitAsciiWhitespace<'ch>

§

impl<'ch> UnwindSafe for rustmax::rayon::str::SplitWhitespace<'ch>

§

impl<'ch, P> UnwindSafe for rustmax::rayon::str::MatchIndices<'ch, P>
where P: UnwindSafe,

§

impl<'ch, P> UnwindSafe for rustmax::rayon::str::Matches<'ch, P>
where P: UnwindSafe,

§

impl<'ch, P> UnwindSafe for rustmax::rayon::str::Split<'ch, P>
where P: UnwindSafe,

§

impl<'ch, P> UnwindSafe for rustmax::rayon::str::SplitInclusive<'ch, P>
where P: UnwindSafe,

§

impl<'ch, P> UnwindSafe for rustmax::rayon::str::SplitTerminator<'ch, P>
where P: UnwindSafe,

§

impl<'d> !UnwindSafe for ValueSerializer<'d>

§

impl<'d> !UnwindSafe for rustmax::toml::Serializer<'d>

§

impl<'d> UnwindSafe for TimeZoneName<'d>

§

impl<'d> UnwindSafe for TimeZoneNameIter<'d>

§

impl<'data> !UnwindSafe for BorrowedBuf<'data>

§

impl<'data, T> !UnwindSafe for rustmax::rayon::slice::ChunksExactMut<'data, T>

§

impl<'data, T> !UnwindSafe for rustmax::rayon::slice::ChunksMut<'data, T>

§

impl<'data, T> !UnwindSafe for rustmax::rayon::slice::IterMut<'data, T>

§

impl<'data, T> !UnwindSafe for rustmax::rayon::slice::RChunksExactMut<'data, T>

§

impl<'data, T> !UnwindSafe for rustmax::rayon::slice::RChunksMut<'data, T>

§

impl<'data, T> !UnwindSafe for rustmax::rayon::vec::Drain<'data, T>

§

impl<'data, T> UnwindSafe for rustmax::rayon::slice::Chunks<'data, T>
where T: RefUnwindSafe,

§

impl<'data, T> UnwindSafe for rustmax::rayon::slice::ChunksExact<'data, T>
where T: RefUnwindSafe,

§

impl<'data, T> UnwindSafe for rustmax::rayon::slice::Iter<'data, T>
where T: RefUnwindSafe,

§

impl<'data, T> UnwindSafe for rustmax::rayon::slice::RChunks<'data, T>
where T: RefUnwindSafe,

§

impl<'data, T> UnwindSafe for rustmax::rayon::slice::RChunksExact<'data, T>
where T: RefUnwindSafe,

§

impl<'data, T> UnwindSafe for rustmax::rayon::slice::Windows<'data, T>
where T: RefUnwindSafe,

§

impl<'data, T, P> !UnwindSafe for rustmax::rayon::slice::ChunkByMut<'data, T, P>

§

impl<'data, T, P> !UnwindSafe for rustmax::rayon::slice::SplitInclusiveMut<'data, T, P>

§

impl<'data, T, P> !UnwindSafe for rustmax::rayon::slice::SplitMut<'data, T, P>

§

impl<'data, T, P> UnwindSafe for rustmax::rayon::slice::ChunkBy<'data, T, P>

§

impl<'data, T, P> UnwindSafe for rustmax::rayon::slice::Split<'data, T, P>

§

impl<'data, T, P> UnwindSafe for rustmax::rayon::slice::SplitInclusive<'data, T, P>

§

impl<'de> UnwindSafe for rustmax::json5::Deserializer<'de>

§

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

§

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

§

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

§

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

§

impl<'e, E, R> UnwindSafe for DecoderReader<'e, E, R>

§

impl<'e, E, S> UnwindSafe for EncoderStringWriter<'e, E, S>

§

impl<'e, E, W> UnwindSafe for EncoderWriter<'e, E, W>

§

impl<'env> !UnwindSafe for rustmax::crossbeam::thread::Scope<'env>

§

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

§

impl<'f> UnwindSafe for rustmax::jiff::fmt::strtime::Display<'f>

§

impl<'fd> UnwindSafe for BorrowedFd<'fd>

§

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

§

impl<'g, T> UnwindSafe for rustmax::crossbeam::epoch::Shared<'g, T>
where T: RefUnwindSafe + ?Sized,

§

impl<'g, T, P> UnwindSafe for CompareExchangeError<'g, T, P>
where P: UnwindSafe, T: RefUnwindSafe + ?Sized,

§

impl<'h> !UnwindSafe for rustmax::rustyline::Context<'h>

§

impl<'h> UnwindSafe for rustmax::regex::bytes::Captures<'h>

§

impl<'h> UnwindSafe for rustmax::regex::bytes::Match<'h>

§

impl<'h> UnwindSafe for rustmax::regex::Captures<'h>

§

impl<'h> UnwindSafe for rustmax::regex::Match<'h>

§

impl<'i> !UnwindSafe for ValidationContext<'i>

§

impl<'i> UnwindSafe for DeValue<'i>

§

impl<'i> UnwindSafe for DeArray<'i>

§

impl<'i> UnwindSafe for DeFloat<'i>

§

impl<'i> UnwindSafe for DeInteger<'i>

§

impl<'i> UnwindSafe for ValueDeserializer<'i>

§

impl<'i> UnwindSafe for rustmax::toml::Deserializer<'i>

§

impl<'n> UnwindSafe for TimeZoneAnnotationKind<'n>

§

impl<'n> UnwindSafe for Pieces<'n>

§

impl<'n> UnwindSafe for TimeZoneAnnotation<'n>

§

impl<'n> UnwindSafe for TimeZoneAnnotationName<'n>

§

impl<'r> !UnwindSafe for EventContext<'r>

§

impl<'r> UnwindSafe for rustmax::regex::bytes::CaptureNames<'r>

§

impl<'r> UnwindSafe for rustmax::regex::CaptureNames<'r>

§

impl<'r, 'h> UnwindSafe for rustmax::regex::bytes::CaptureMatches<'r, 'h>

§

impl<'r, 'h> UnwindSafe for rustmax::regex::bytes::Matches<'r, 'h>

§

impl<'r, 'h> UnwindSafe for rustmax::regex::bytes::Split<'r, 'h>

§

impl<'r, 'h> UnwindSafe for rustmax::regex::bytes::SplitN<'r, 'h>

§

impl<'r, 'h> UnwindSafe for rustmax::regex::CaptureMatches<'r, 'h>

§

impl<'r, 'h> UnwindSafe for rustmax::regex::Matches<'r, 'h>

§

impl<'r, 'h> UnwindSafe for rustmax::regex::Split<'r, 'h>

§

impl<'r, 'h> UnwindSafe for rustmax::regex::SplitN<'r, 'h>

§

impl<'s> UnwindSafe for rustmax::regex::bytes::NoExpand<'s>

§

impl<'s> UnwindSafe for rustmax::regex::NoExpand<'s>

§

impl<'s> UnwindSafe for SockRef<'s>

§

impl<'scope> !UnwindSafe for rustmax::rayon::Scope<'scope>

§

impl<'scope> !UnwindSafe for ScopeFifo<'scope>

§

impl<'scope, 'env> !UnwindSafe for rustmax::std::thread::Scope<'scope, 'env>

§

impl<'scope, 'env> UnwindSafe for ScopedThreadBuilder<'scope, 'env>

§

impl<'scope, T> !UnwindSafe for rustmax::std::thread::ScopedJoinHandle<'scope, T>

§

impl<'scope, T> UnwindSafe for rustmax::crossbeam::thread::ScopedJoinHandle<'scope, T>

§

impl<'t> UnwindSafe for TimeZoneFollowingTransitions<'t>

§

impl<'t> UnwindSafe for TimeZoneOffsetInfo<'t>

§

impl<'t> UnwindSafe for TimeZonePrecedingTransitions<'t>

§

impl<'t> UnwindSafe for TimeZoneTransition<'t>

§

impl<A> UnwindSafe for rustmax::core::option::IntoIter<A>
where A: UnwindSafe,

§

impl<A> UnwindSafe for IterRange<A>
where A: UnwindSafe,

§

impl<A> UnwindSafe for IterRangeFrom<A>
where A: UnwindSafe,

§

impl<A> UnwindSafe for IterRangeInclusive<A>
where A: UnwindSafe,

§

impl<A> UnwindSafe for rustmax::itertools::__std_iter::Repeat<A>
where A: UnwindSafe,

§

impl<A> UnwindSafe for rustmax::itertools::__std_iter::RepeatN<A>
where A: UnwindSafe,

§

impl<A> UnwindSafe for rustmax::itertools::RepeatN<A>
where A: UnwindSafe,

§

impl<A> UnwindSafe for EnumAccessDeserializer<A>
where A: UnwindSafe,

§

impl<A> UnwindSafe for MapAccessDeserializer<A>
where A: UnwindSafe,

§

impl<A> UnwindSafe for SeqAccessDeserializer<A>
where A: UnwindSafe,

§

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

§

impl<A, B> UnwindSafe for rustmax::prelude::Either<A, B>
where A: UnwindSafe, B: UnwindSafe,

§

impl<A, B> UnwindSafe for rustmax::tower::util::Either<A, B>
where A: UnwindSafe, B: UnwindSafe,

§

impl<A, B> UnwindSafe for rustmax::itertools::__std_iter::Chain<A, B>
where A: UnwindSafe, B: UnwindSafe,

§

impl<A, B> UnwindSafe for rustmax::itertools::__std_iter::Zip<A, B>
where A: UnwindSafe, B: UnwindSafe,

§

impl<A, B> UnwindSafe for rustmax::prelude::future::Select<A, B>
where A: UnwindSafe, B: UnwindSafe,

§

impl<A, B> UnwindSafe for TrySelect<A, B>
where A: UnwindSafe, B: UnwindSafe,

§

impl<A, B> UnwindSafe for rustmax::rayon::iter::Chain<A, B>
where A: UnwindSafe, B: UnwindSafe,

§

impl<A, B> UnwindSafe for rustmax::rayon::iter::Zip<A, B>
where A: UnwindSafe, B: UnwindSafe,

§

impl<A, B> UnwindSafe for rustmax::rayon::iter::ZipEq<A, B>
where A: UnwindSafe, B: UnwindSafe,

§

impl<A, B> UnwindSafe for EitherResponseFuture<A, B>
where A: UnwindSafe, B: UnwindSafe,

§

impl<B> !UnwindSafe for rustmax::hyper::client::conn::http1::SendRequest<B>

§

impl<B> !UnwindSafe for rustmax::hyper::client::conn::http2::SendRequest<B>

§

impl<B> UnwindSafe for rustmax::bitflags::iter::Iter<B>

§

impl<B> UnwindSafe for IterNames<B>

§

impl<B> UnwindSafe for Flag<B>
where B: UnwindSafe,

§

impl<B> UnwindSafe for Reader<B>
where B: UnwindSafe,

§

impl<B> UnwindSafe for Writer<B>
where B: UnwindSafe,

§

impl<B> UnwindSafe for rustmax::std::io::Lines<B>
where B: UnwindSafe,

§

impl<B> UnwindSafe for rustmax::std::io::Split<B>
where B: UnwindSafe,

§

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

§

impl<B, S = ()> !UnwindSafe for RouterIntoService<B, S>

§

impl<B, T, E, S> !UnwindSafe for rustmax::axum::middleware::future::FromExtractorResponseFuture<B, T, E, S>

§

impl<BlockSize, Kind> UnwindSafe for BlockBuffer<BlockSize, Kind>
where <BlockSize as ArrayLength<u8>>::ArrayType: UnwindSafe, Kind: UnwindSafe,

§

impl<D, C> UnwindSafe for PeakEwmaDiscover<D, C>
where D: UnwindSafe, C: UnwindSafe,

§

impl<D, C> UnwindSafe for PendingRequestsDiscover<D, C>
where D: UnwindSafe, C: UnwindSafe,

§

impl<D, F, T, S> UnwindSafe for rustmax::rand::distr::Map<D, F, T, S>
where D: UnwindSafe, F: UnwindSafe,

§

impl<D, R, T> UnwindSafe for rustmax::rand::distr::Iter<D, R, T>
where D: UnwindSafe, R: UnwindSafe, T: UnwindSafe,

§

impl<D, Req> !UnwindSafe for Balance<D, Req>

§

impl<D, Req> UnwindSafe for MakeBalanceLayer<D, Req>

§

impl<D, S> UnwindSafe for rustmax::rayon::iter::Split<D, S>
where D: UnwindSafe, S: UnwindSafe,

§

impl<Dyn> !UnwindSafe for DynMetadata<Dyn>

§

impl<E = Infallible> !UnwindSafe for Route<E>

§

impl<E> !UnwindSafe for RouteFuture<E>

§

impl<E> !UnwindSafe for rustmax::hyper::server::conn::http2::Builder<E>

§

impl<E> UnwindSafe for EnumValueParser<E>
where E: UnwindSafe,

§

impl<E> UnwindSafe for rustmax::nom::bytes::Take<E>
where E: UnwindSafe,

§

impl<E> UnwindSafe for AnyChar<E>
where E: UnwindSafe,

§

impl<E> UnwindSafe for Char<E>
where E: UnwindSafe,

§

impl<E> UnwindSafe for Digit1<E>
where E: UnwindSafe,

§

impl<E> UnwindSafe for MultiSpace0<E>
where E: UnwindSafe,

§

impl<E> UnwindSafe for BoolDeserializer<E>
where E: UnwindSafe,

§

impl<E> UnwindSafe for CharDeserializer<E>
where E: UnwindSafe,

§

impl<E> UnwindSafe for F32Deserializer<E>
where E: UnwindSafe,

§

impl<E> UnwindSafe for F64Deserializer<E>
where E: UnwindSafe,

§

impl<E> UnwindSafe for I8Deserializer<E>
where E: UnwindSafe,

§

impl<E> UnwindSafe for I16Deserializer<E>
where E: UnwindSafe,

§

impl<E> UnwindSafe for I32Deserializer<E>
where E: UnwindSafe,

§

impl<E> UnwindSafe for I64Deserializer<E>
where E: UnwindSafe,

§

impl<E> UnwindSafe for I128Deserializer<E>
where E: UnwindSafe,

§

impl<E> UnwindSafe for IsizeDeserializer<E>
where E: UnwindSafe,

§

impl<E> UnwindSafe for StringDeserializer<E>
where E: UnwindSafe,

§

impl<E> UnwindSafe for U8Deserializer<E>
where E: UnwindSafe,

§

impl<E> UnwindSafe for U16Deserializer<E>
where E: UnwindSafe,

§

impl<E> UnwindSafe for U32Deserializer<E>
where E: UnwindSafe,

§

impl<E> UnwindSafe for U64Deserializer<E>
where E: UnwindSafe,

§

impl<E> UnwindSafe for U128Deserializer<E>
where E: UnwindSafe,

§

impl<E> UnwindSafe for UnitDeserializer<E>
where E: UnwindSafe,

§

impl<E> UnwindSafe for UsizeDeserializer<E>
where E: UnwindSafe,

§

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

§

impl<E, M> UnwindSafe for Capture<E, M>
where E: UnwindSafe, M: UnwindSafe,

§

impl<E, S> UnwindSafe for FromExtractorLayer<E, S>
where S: UnwindSafe,

§

impl<Enum> UnwindSafe for TryFromPrimitiveError<Enum>

§

impl<Ex> !UnwindSafe for rustmax::hyper::client::conn::http2::Builder<Ex>

§

impl<F1, F2, N> UnwindSafe for AndThenFuture<F1, F2, N>
where F2: UnwindSafe, N: UnwindSafe, F1: UnwindSafe,

§

impl<F1, F2, N> UnwindSafe for ThenFuture<F1, F2, N>
where F2: UnwindSafe, F1: UnwindSafe, N: UnwindSafe,

§

impl<F = RichFormatter> !UnwindSafe for rustmax::clap::error::Error<F>

§

impl<F = File> !UnwindSafe for PersistError<F>

§

impl<F> !UnwindSafe for JoinAll<F>

§

impl<F> !UnwindSafe for TryJoinAll<F>

§

impl<F> UnwindSafe for IntoServiceFuture<F>
where F: UnwindSafe,

§

impl<F> UnwindSafe for rustmax::core::fmt::FromFn<F>
where F: UnwindSafe,

§

impl<F> UnwindSafe for rustmax::core::future::PollFn<F>
where F: UnwindSafe,

§

impl<F> UnwindSafe for rustmax::itertools::__std_iter::FromFn<F>
where F: UnwindSafe,

§

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

§

impl<F> UnwindSafe for rustmax::itertools::__std_iter::RepeatWith<F>
where F: UnwindSafe,

§

impl<F> UnwindSafe for AllConsuming<F>
where F: UnwindSafe,

§

impl<F> UnwindSafe for Cond<F>
where F: UnwindSafe,

§

impl<F> UnwindSafe for Consumed<F>
where F: UnwindSafe,

§

impl<F> UnwindSafe for Cut<F>
where F: UnwindSafe,

§

impl<F> UnwindSafe for MakeComplete<F>
where F: UnwindSafe,

§

impl<F> UnwindSafe for rustmax::nom::combinator::Not<F>
where F: UnwindSafe,

§

impl<F> UnwindSafe for Opt<F>
where F: UnwindSafe,

§

impl<F> UnwindSafe for rustmax::nom::combinator::Peek<F>
where F: UnwindSafe,

§

impl<F> UnwindSafe for Recognize<F>
where F: UnwindSafe,

§

impl<F> UnwindSafe for rustmax::nom::error::Context<F>
where F: UnwindSafe,

§

impl<F> UnwindSafe for rustmax::nom::multi::Count<F>
where F: UnwindSafe,

§

impl<F> UnwindSafe for Many0<F>
where F: UnwindSafe,

§

impl<F> UnwindSafe for Many0Count<F>
where F: UnwindSafe,

§

impl<F> UnwindSafe for Many1<F>
where F: UnwindSafe,

§

impl<F> UnwindSafe for Many1Count<F>
where F: UnwindSafe,

§

impl<F> UnwindSafe for ManyMN<F>
where F: UnwindSafe,

§

impl<F> UnwindSafe for rustmax::prelude::future::Flatten<F>
where F: UnwindSafe, <F as Future>::Output: UnwindSafe,

§

impl<F> UnwindSafe for FlattenStream<F>
where F: UnwindSafe, <F as Future>::Output: UnwindSafe,

§

impl<F> UnwindSafe for rustmax::prelude::future::IntoStream<F>
where F: UnwindSafe,

§

impl<F> UnwindSafe for rustmax::prelude::future::Lazy<F>
where F: UnwindSafe,

§

impl<F> UnwindSafe for OptionFuture<F>
where F: UnwindSafe,

§

impl<F> UnwindSafe for rustmax::prelude::future::PollFn<F>
where F: UnwindSafe,

§

impl<F> UnwindSafe for rustmax::prelude::stream::PollFn<F>
where F: UnwindSafe,

§

impl<F> UnwindSafe for rustmax::prelude::stream::RepeatWith<F>
where F: UnwindSafe,

§

impl<F> UnwindSafe for NamedTempFile<F>
where F: UnwindSafe,

§

impl<F> UnwindSafe for Unconstrained<F>
where F: UnwindSafe,

§

impl<F> UnwindSafe for LayerFn<F>
where F: UnwindSafe,

§

impl<F> UnwindSafe for rustmax::tower::load_shed::future::ResponseFuture<F>
where F: UnwindSafe,

§

impl<F> UnwindSafe for AndThenLayer<F>
where F: UnwindSafe,

§

impl<F> UnwindSafe for MapErrLayer<F>
where F: UnwindSafe,

§

impl<F> UnwindSafe for MapFutureLayer<F>
where F: UnwindSafe,

§

impl<F> UnwindSafe for rustmax::tower::util::MapRequestLayer<F>
where F: UnwindSafe,

§

impl<F> UnwindSafe for rustmax::tower::util::MapResponseLayer<F>
where F: UnwindSafe,

§

impl<F> UnwindSafe for MapResultLayer<F>
where F: UnwindSafe,

§

impl<F> UnwindSafe for ThenLayer<F>
where F: UnwindSafe,

§

impl<F, C, H> UnwindSafe for TrackCompletionFuture<F, C, H>
where F: UnwindSafe, C: UnwindSafe, H: UnwindSafe,

§

impl<F, E> UnwindSafe for SplitPosition1<F, E>
where F: UnwindSafe, E: UnwindSafe,

§

impl<F, E> UnwindSafe for SplitPosition<F, E>
where F: UnwindSafe, E: UnwindSafe,

§

impl<F, E> UnwindSafe for TakeWhileMN<F, E>
where F: UnwindSafe, E: UnwindSafe,

§

impl<F, E> UnwindSafe for rustmax::tower::reconnect::ResponseFuture<F, E>
where F: UnwindSafe, E: UnwindSafe,

§

impl<F, E> UnwindSafe for rustmax::tower::spawn_ready::future::ResponseFuture<F, E>
where F: UnwindSafe,

§

impl<F, G> UnwindSafe for SeparatedList0<F, G>
where F: UnwindSafe, G: UnwindSafe,

§

impl<F, G> UnwindSafe for SeparatedList1<F, G>
where F: UnwindSafe, G: UnwindSafe,

§

impl<F, G> UnwindSafe for Preceded<F, G>
where F: UnwindSafe, G: UnwindSafe,

§

impl<F, G> UnwindSafe for Terminated<F, G>
where F: UnwindSafe, G: UnwindSafe,

§

impl<F, G> UnwindSafe for rustmax::nom::And<F, G>
where F: UnwindSafe, G: UnwindSafe,

§

impl<F, G> UnwindSafe for rustmax::nom::AndThen<F, G>
where F: UnwindSafe, G: UnwindSafe,

§

impl<F, G> UnwindSafe for rustmax::nom::FlatMap<F, G>
where F: UnwindSafe, G: UnwindSafe,

§

impl<F, G> UnwindSafe for rustmax::nom::Map<F, G>
where F: UnwindSafe, G: UnwindSafe,

§

impl<F, G> UnwindSafe for MapOpt<F, G>
where F: UnwindSafe, G: UnwindSafe,

§

impl<F, G> UnwindSafe for MapRes<F, G>
where F: UnwindSafe, G: UnwindSafe,

§

impl<F, G> UnwindSafe for rustmax::nom::Or<F, G>
where F: UnwindSafe, G: UnwindSafe,

§

impl<F, G, E> UnwindSafe for Escaped<F, G, E>
where F: UnwindSafe, G: UnwindSafe, E: UnwindSafe,

§

impl<F, G, E> UnwindSafe for LengthCount<F, G, E>
where F: UnwindSafe, G: UnwindSafe, E: UnwindSafe,

§

impl<F, G, E> UnwindSafe for LengthValue<F, G, E>
where F: UnwindSafe, G: UnwindSafe, E: UnwindSafe,

§

impl<F, G, E> UnwindSafe for ManyTill<F, G, E>
where F: UnwindSafe, G: UnwindSafe, E: UnwindSafe,

§

impl<F, G, E, ExtendItem, Output> UnwindSafe for EscapedTransform<F, G, E, ExtendItem, Output>
where F: UnwindSafe, G: UnwindSafe, E: UnwindSafe, ExtendItem: UnwindSafe, Output: UnwindSafe,

§

impl<F, G, H, Range> UnwindSafe for rustmax::nom::multi::Fold<F, G, H, Range>
where F: UnwindSafe, H: UnwindSafe, G: UnwindSafe, Range: UnwindSafe,

§

impl<F, G, Init, R> UnwindSafe for FoldMany0<F, G, Init, R>
where F: UnwindSafe, G: UnwindSafe, Init: UnwindSafe, R: UnwindSafe,

§

impl<F, G, Init, R> UnwindSafe for FoldMany1<F, G, Init, R>
where F: UnwindSafe, G: UnwindSafe, Init: UnwindSafe, R: UnwindSafe,

§

impl<F, G, Init, R> UnwindSafe for FoldManyMN<F, G, Init, R>
where F: UnwindSafe, G: UnwindSafe, Init: UnwindSafe, R: UnwindSafe,

§

impl<F, G, O2> UnwindSafe for Verify<F, G, O2>
where F: UnwindSafe, G: UnwindSafe, O2: UnwindSafe + ?Sized,

§

impl<F, MakeError> UnwindSafe for Satisfy<F, MakeError>
where F: UnwindSafe, MakeError: UnwindSafe,

§

impl<F, N> UnwindSafe for MapErrFuture<F, N>
where F: UnwindSafe, N: UnwindSafe,

§

impl<F, N> UnwindSafe for MapResponseFuture<F, N>
where F: UnwindSafe, N: UnwindSafe,

§

impl<F, N> UnwindSafe for MapResultFuture<F, N>
where F: UnwindSafe, N: UnwindSafe,

§

impl<F, O2, E2> UnwindSafe for Into<F, O2, E2>
where F: UnwindSafe, O2: UnwindSafe, E2: UnwindSafe,

§

impl<F, R, Collection> UnwindSafe for Many<F, R, Collection>
where F: UnwindSafe, R: UnwindSafe, Collection: UnwindSafe,

§

impl<F, Req> UnwindSafe for MakeFuture<F, Req>
where F: UnwindSafe,

§

impl<F, S> UnwindSafe for FutureService<F, S>
where F: UnwindSafe, S: UnwindSafe,

§

impl<F, S, I, T> UnwindSafe for rustmax::axum::middleware::FromFn<F, S, I, T>
where F: UnwindSafe, I: UnwindSafe, S: UnwindSafe,

§

impl<F, S, I, T> UnwindSafe for rustmax::axum::middleware::MapRequest<F, S, I, T>
where F: UnwindSafe, I: UnwindSafe, S: UnwindSafe,

§

impl<F, S, I, T> UnwindSafe for rustmax::axum::middleware::MapResponse<F, S, I, T>
where F: UnwindSafe, I: UnwindSafe, S: UnwindSafe,

§

impl<F, S, T> UnwindSafe for FromFnLayer<F, S, T>
where F: UnwindSafe, S: UnwindSafe,

§

impl<F, S, T> UnwindSafe for rustmax::axum::middleware::MapRequestLayer<F, S, T>
where F: UnwindSafe, S: UnwindSafe,

§

impl<F, S, T> UnwindSafe for rustmax::axum::middleware::MapResponseLayer<F, S, T>
where F: UnwindSafe, S: UnwindSafe,

§

impl<F, T> UnwindSafe for HandleErrorLayer<F, T>
where F: UnwindSafe,

§

impl<Failure, Error> UnwindSafe for Err<Failure, Error>
where Error: UnwindSafe, Failure: UnwindSafe,

§

impl<Fut1, Fut2> UnwindSafe for rustmax::prelude::future::Join<Fut1, Fut2>
where Fut1: UnwindSafe, <Fut1 as Future>::Output: UnwindSafe, Fut2: UnwindSafe, <Fut2 as Future>::Output: UnwindSafe,

§

impl<Fut1, Fut2> UnwindSafe for rustmax::prelude::future::TryFlatten<Fut1, Fut2>
where Fut1: UnwindSafe, Fut2: UnwindSafe,

§

impl<Fut1, Fut2> UnwindSafe for TryJoin<Fut1, Fut2>
where Fut1: UnwindSafe, <Fut1 as TryFuture>::Ok: UnwindSafe, Fut2: UnwindSafe, <Fut2 as TryFuture>::Ok: UnwindSafe,

§

impl<Fut1, Fut2, F> UnwindSafe for rustmax::prelude::future::AndThen<Fut1, Fut2, F>
where Fut2: UnwindSafe, Fut1: UnwindSafe, F: UnwindSafe,

§

impl<Fut1, Fut2, F> UnwindSafe for rustmax::prelude::future::OrElse<Fut1, Fut2, F>
where Fut2: UnwindSafe, Fut1: UnwindSafe, F: UnwindSafe,

§

impl<Fut1, Fut2, F> UnwindSafe for rustmax::prelude::future::Then<Fut1, Fut2, F>
where Fut2: UnwindSafe, Fut1: UnwindSafe, F: UnwindSafe,

§

impl<Fut1, Fut2, Fut3> UnwindSafe for Join3<Fut1, Fut2, Fut3>
where Fut1: UnwindSafe, <Fut1 as Future>::Output: UnwindSafe, Fut2: UnwindSafe, <Fut2 as Future>::Output: UnwindSafe, Fut3: UnwindSafe, <Fut3 as Future>::Output: UnwindSafe,

§

impl<Fut1, Fut2, Fut3> UnwindSafe for TryJoin3<Fut1, Fut2, Fut3>
where Fut1: UnwindSafe, <Fut1 as TryFuture>::Ok: UnwindSafe, Fut2: UnwindSafe, <Fut2 as TryFuture>::Ok: UnwindSafe, Fut3: UnwindSafe, <Fut3 as TryFuture>::Ok: UnwindSafe,

§

impl<Fut1, Fut2, Fut3, Fut4> UnwindSafe for Join4<Fut1, Fut2, Fut3, Fut4>
where Fut1: UnwindSafe, <Fut1 as Future>::Output: UnwindSafe, Fut2: UnwindSafe, <Fut2 as Future>::Output: UnwindSafe, Fut3: UnwindSafe, <Fut3 as Future>::Output: UnwindSafe, Fut4: UnwindSafe, <Fut4 as Future>::Output: UnwindSafe,

§

impl<Fut1, Fut2, Fut3, Fut4> UnwindSafe for TryJoin4<Fut1, Fut2, Fut3, Fut4>
where Fut1: UnwindSafe, <Fut1 as TryFuture>::Ok: UnwindSafe, Fut2: UnwindSafe, <Fut2 as TryFuture>::Ok: UnwindSafe, Fut3: UnwindSafe, <Fut3 as TryFuture>::Ok: UnwindSafe, Fut4: UnwindSafe, <Fut4 as TryFuture>::Ok: UnwindSafe,

§

impl<Fut1, Fut2, Fut3, Fut4, Fut5> UnwindSafe for Join5<Fut1, Fut2, Fut3, Fut4, Fut5>
where Fut1: UnwindSafe, <Fut1 as Future>::Output: UnwindSafe, Fut2: UnwindSafe, <Fut2 as Future>::Output: UnwindSafe, Fut3: UnwindSafe, <Fut3 as Future>::Output: UnwindSafe, Fut4: UnwindSafe, <Fut4 as Future>::Output: UnwindSafe, Fut5: UnwindSafe, <Fut5 as Future>::Output: UnwindSafe,

§

impl<Fut1, Fut2, Fut3, Fut4, Fut5> UnwindSafe for TryJoin5<Fut1, Fut2, Fut3, Fut4, Fut5>
where Fut1: UnwindSafe, <Fut1 as TryFuture>::Ok: UnwindSafe, Fut2: UnwindSafe, <Fut2 as TryFuture>::Ok: UnwindSafe, Fut3: UnwindSafe, <Fut3 as TryFuture>::Ok: UnwindSafe, Fut4: UnwindSafe, <Fut4 as TryFuture>::Ok: UnwindSafe, Fut5: UnwindSafe, <Fut5 as TryFuture>::Ok: UnwindSafe,

§

impl<Fut> !UnwindSafe for Remote<Fut>

§

impl<Fut> !UnwindSafe for rustmax::prelude::future::Shared<Fut>

§

impl<Fut> !UnwindSafe for WeakShared<Fut>

§

impl<Fut> !UnwindSafe for rustmax::prelude::stream::futures_unordered::IntoIter<Fut>

§

impl<Fut> !UnwindSafe for FuturesUnordered<Fut>

§

impl<Fut> UnwindSafe for MaybeDone<Fut>
where Fut: UnwindSafe, <Fut as Future>::Output: UnwindSafe,

§

impl<Fut> UnwindSafe for TryMaybeDone<Fut>
where Fut: UnwindSafe, <Fut as TryFuture>::Ok: UnwindSafe,

§

impl<Fut> UnwindSafe for rustmax::prelude::future::CatchUnwind<Fut>
where Fut: UnwindSafe,

§

impl<Fut> UnwindSafe for rustmax::prelude::future::Fuse<Fut>
where Fut: UnwindSafe,

§

impl<Fut> UnwindSafe for IntoFuture<Fut>
where Fut: UnwindSafe,

§

impl<Fut> UnwindSafe for NeverError<Fut>
where Fut: UnwindSafe,

§

impl<Fut> UnwindSafe for rustmax::prelude::future::SelectAll<Fut>
where Fut: UnwindSafe,

§

impl<Fut> UnwindSafe for SelectOk<Fut>
where Fut: UnwindSafe,

§

impl<Fut> UnwindSafe for TryFlattenStream<Fut>
where Fut: UnwindSafe, <Fut as TryFuture>::Ok: UnwindSafe,

§

impl<Fut> UnwindSafe for rustmax::prelude::future::UnitError<Fut>
where Fut: UnwindSafe,

§

impl<Fut> UnwindSafe for rustmax::prelude::stream::Once<Fut>
where Fut: UnwindSafe,

§

impl<Fut, E> UnwindSafe for rustmax::prelude::future::ErrInto<Fut, E>
where Fut: UnwindSafe,

§

impl<Fut, E> UnwindSafe for OkInto<Fut, E>
where Fut: UnwindSafe,

§

impl<Fut, F> UnwindSafe for rustmax::prelude::future::Inspect<Fut, F>
where Fut: UnwindSafe, F: UnwindSafe,

§

impl<Fut, F> UnwindSafe for rustmax::prelude::future::InspectErr<Fut, F>
where Fut: UnwindSafe, F: UnwindSafe,

§

impl<Fut, F> UnwindSafe for rustmax::prelude::future::InspectOk<Fut, F>
where Fut: UnwindSafe, F: UnwindSafe,

§

impl<Fut, F> UnwindSafe for rustmax::prelude::future::Map<Fut, F>
where Fut: UnwindSafe, F: UnwindSafe,

§

impl<Fut, F> UnwindSafe for rustmax::prelude::future::MapErr<Fut, F>
where Fut: UnwindSafe, F: UnwindSafe,

§

impl<Fut, F> UnwindSafe for rustmax::prelude::future::MapOk<Fut, F>
where Fut: UnwindSafe, F: UnwindSafe,

§

impl<Fut, F> UnwindSafe for UnwrapOrElse<Fut, F>
where Fut: UnwindSafe, F: UnwindSafe,

§

impl<Fut, F, G> UnwindSafe for MapOkOrElse<Fut, F, G>
where Fut: UnwindSafe, F: UnwindSafe, G: UnwindSafe,

§

impl<Fut, Si> UnwindSafe for FlattenSink<Fut, Si>
where Fut: UnwindSafe, Si: UnwindSafe,

§

impl<Fut, T> UnwindSafe for rustmax::prelude::future::MapInto<Fut, T>
where Fut: UnwindSafe,

§

impl<G> UnwindSafe for FromCoroutine<G>
where G: UnwindSafe,

§

impl<H> UnwindSafe for BuildHasherDefault<H>

§

impl<H> UnwindSafe for HasherRng<H>
where H: UnwindSafe,

§

impl<H, I> !UnwindSafe for Editor<H, I>

§

impl<H, T, S> UnwindSafe for HandlerService<H, T, S>
where H: UnwindSafe, S: UnwindSafe,

§

impl<I> !UnwindSafe for RcIter<I>

§

impl<I> !UnwindSafe for Tee<I>

§

impl<I> UnwindSafe for AppendHeaders<I>
where I: UnwindSafe,

§

impl<I> UnwindSafe for DelayedFormat<I>
where I: UnwindSafe,

§

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

§

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

§

impl<I> UnwindSafe for rustmax::itertools::__std_iter::Cloned<I>
where I: UnwindSafe,

§

impl<I> UnwindSafe for rustmax::itertools::__std_iter::Copied<I>
where I: UnwindSafe,

§

impl<I> UnwindSafe for rustmax::itertools::__std_iter::Cycle<I>
where I: UnwindSafe,

§

impl<I> UnwindSafe for rustmax::itertools::__std_iter::Enumerate<I>
where I: UnwindSafe,

§

impl<I> UnwindSafe for rustmax::itertools::__std_iter::Flatten<I>

§

impl<I> UnwindSafe for rustmax::itertools::__std_iter::Fuse<I>
where I: UnwindSafe,

§

impl<I> UnwindSafe for rustmax::itertools::__std_iter::Intersperse<I>
where <I as Iterator>::Item: Sized + UnwindSafe, I: UnwindSafe,

§

impl<I> UnwindSafe for rustmax::itertools::__std_iter::Peekable<I>
where I: UnwindSafe, <I as Iterator>::Item: UnwindSafe,

§

impl<I> UnwindSafe for rustmax::itertools::__std_iter::Skip<I>
where I: UnwindSafe,

§

impl<I> UnwindSafe for rustmax::itertools::__std_iter::StepBy<I>
where I: UnwindSafe,

§

impl<I> UnwindSafe for rustmax::itertools::__std_iter::Take<I>
where I: UnwindSafe,

§

impl<I> UnwindSafe for CombinationsWithReplacement<I>
where <I as Iterator>::Item: Sized + UnwindSafe, I: UnwindSafe,

§

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

§

impl<I> UnwindSafe for GroupingMap<I>
where I: UnwindSafe,

§

impl<I> UnwindSafe for IntoChunks<I>

§

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

§

impl<I> UnwindSafe for MultiProduct<I>
where <I as Iterator>::Item: Sized + UnwindSafe, I: UnwindSafe,

§

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

§

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

§

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

§

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

§

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

§

impl<I> UnwindSafe for Unique<I>
where <I as Iterator>::Item: Sized + UnwindSafe, I: UnwindSafe,

§

impl<I> UnwindSafe for rustmax::itertools::WhileSome<I>
where I: UnwindSafe,

§

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

§

impl<I> UnwindSafe for rustmax::nom::error::Error<I>
where I: UnwindSafe,

§

impl<I> UnwindSafe for rustmax::prelude::stream::Iter<I>
where I: UnwindSafe,

§

impl<I> UnwindSafe for rustmax::rayon::iter::Chunks<I>
where I: UnwindSafe,

§

impl<I> UnwindSafe for rustmax::rayon::iter::Cloned<I>
where I: UnwindSafe,

§

impl<I> UnwindSafe for rustmax::rayon::iter::Copied<I>
where I: UnwindSafe,

§

impl<I> UnwindSafe for rustmax::rayon::iter::Enumerate<I>
where I: UnwindSafe,

§

impl<I> UnwindSafe for ExponentialBlocks<I>
where I: UnwindSafe,

§

impl<I> UnwindSafe for rustmax::rayon::iter::Flatten<I>
where I: UnwindSafe,

§

impl<I> UnwindSafe for FlattenIter<I>
where I: UnwindSafe,

§

impl<I> UnwindSafe for rustmax::rayon::iter::Intersperse<I>

§

impl<I> UnwindSafe for MaxLen<I>
where I: UnwindSafe,

§

impl<I> UnwindSafe for MinLen<I>
where I: UnwindSafe,

§

impl<I> UnwindSafe for PanicFuse<I>
where I: UnwindSafe,

§

impl<I> UnwindSafe for rustmax::rayon::iter::Rev<I>
where I: UnwindSafe,

§

impl<I> UnwindSafe for rustmax::rayon::iter::Skip<I>
where I: UnwindSafe,

§

impl<I> UnwindSafe for SkipAny<I>
where I: UnwindSafe,

§

impl<I> UnwindSafe for rustmax::rayon::iter::StepBy<I>
where I: UnwindSafe,

§

impl<I> UnwindSafe for rustmax::rayon::iter::Take<I>
where I: UnwindSafe,

§

impl<I> UnwindSafe for TakeAny<I>
where I: UnwindSafe,

§

impl<I> UnwindSafe for UniformBlocks<I>
where I: UnwindSafe,

§

impl<I> UnwindSafe for rustmax::rayon::iter::WhileSome<I>
where I: UnwindSafe,

§

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

§

impl<I, E, F> UnwindSafe for ParserIterator<I, E, F>
where F: UnwindSafe, I: UnwindSafe, E: UnwindSafe,

§

impl<I, ElemF> UnwindSafe for rustmax::itertools::IntersperseWith<I, ElemF>
where ElemF: UnwindSafe, I: UnwindSafe, <I as Iterator>::Item: UnwindSafe,

§

impl<I, F> UnwindSafe for rustmax::itertools::__std_iter::FilterMap<I, F>
where I: UnwindSafe, F: UnwindSafe,

§

impl<I, F> UnwindSafe for rustmax::itertools::__std_iter::Inspect<I, F>
where I: UnwindSafe, F: UnwindSafe,

§

impl<I, F> UnwindSafe for rustmax::itertools::__std_iter::Map<I, F>
where I: UnwindSafe, F: UnwindSafe,

§

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

§

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

§

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

§

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

§

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

§

impl<I, F> UnwindSafe for rustmax::itertools::Positions<I, F>
where F: UnwindSafe, I: UnwindSafe,

§

impl<I, F> UnwindSafe for TakeWhileInclusive<I, F>
where I: UnwindSafe, F: UnwindSafe,

§

impl<I, F> UnwindSafe for rustmax::itertools::Update<I, F>
where I: UnwindSafe, F: UnwindSafe,

§

impl<I, F> UnwindSafe for rustmax::rayon::iter::FlatMap<I, F>
where I: UnwindSafe, F: UnwindSafe,

§

impl<I, F> UnwindSafe for FlatMapIter<I, F>
where I: UnwindSafe, F: UnwindSafe,

§

impl<I, F> UnwindSafe for rustmax::rayon::iter::Inspect<I, F>
where I: UnwindSafe, F: UnwindSafe,

§

impl<I, F> UnwindSafe for rustmax::rayon::iter::Map<I, F>
where I: UnwindSafe, F: UnwindSafe,

§

impl<I, F> UnwindSafe for rustmax::rayon::iter::Update<I, F>
where I: UnwindSafe, F: UnwindSafe,

§

impl<I, F, const N: usize> UnwindSafe for MapWindows<I, F, N>
where F: UnwindSafe, I: UnwindSafe, <I as Iterator>::Item: UnwindSafe,

§

impl<I, G> UnwindSafe for rustmax::itertools::__std_iter::IntersperseWith<I, G>
where G: UnwindSafe, <I as Iterator>::Item: UnwindSafe, I: UnwindSafe,

§

impl<I, ID, F> UnwindSafe for rustmax::rayon::iter::Fold<I, ID, F>
where I: UnwindSafe, ID: UnwindSafe, F: UnwindSafe,

§

impl<I, ID, F> UnwindSafe for FoldChunks<I, ID, F>
where I: UnwindSafe, F: UnwindSafe, ID: UnwindSafe,

§

impl<I, INIT, F> UnwindSafe for MapInit<I, INIT, F>
where I: UnwindSafe, INIT: UnwindSafe, F: UnwindSafe,

§

impl<I, J> UnwindSafe for Diff<I, J>

§

impl<I, J> UnwindSafe for rustmax::itertools::Interleave<I, J>
where I: UnwindSafe, J: UnwindSafe,

§

impl<I, J> UnwindSafe for rustmax::itertools::InterleaveShortest<I, J>
where I: UnwindSafe, J: UnwindSafe,

§

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

§

impl<I, J> UnwindSafe for rustmax::itertools::ZipEq<I, J>
where I: UnwindSafe, J: UnwindSafe,

§

impl<I, J> UnwindSafe for rustmax::rayon::iter::Interleave<I, J>
where I: UnwindSafe, J: UnwindSafe,

§

impl<I, J> UnwindSafe for rustmax::rayon::iter::InterleaveShortest<I, J>
where I: UnwindSafe, J: UnwindSafe,

§

impl<I, J, F> UnwindSafe for MergeBy<I, J, F>

§

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

§

impl<I, P> UnwindSafe for rustmax::itertools::__std_iter::Filter<I, P>
where I: UnwindSafe, P: UnwindSafe,

§

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

§

impl<I, P> UnwindSafe for rustmax::itertools::__std_iter::SkipWhile<I, P>
where I: UnwindSafe, P: UnwindSafe,

§

impl<I, P> UnwindSafe for rustmax::itertools::__std_iter::TakeWhile<I, P>
where I: UnwindSafe, P: UnwindSafe,

§

impl<I, P> UnwindSafe for rustmax::rayon::iter::Filter<I, P>
where I: UnwindSafe, P: UnwindSafe,

§

impl<I, P> UnwindSafe for rustmax::rayon::iter::FilterMap<I, P>
where I: UnwindSafe, P: UnwindSafe,

§

impl<I, P> UnwindSafe for rustmax::rayon::iter::Positions<I, P>
where I: UnwindSafe, P: UnwindSafe,

§

impl<I, P> UnwindSafe for SkipAnyWhile<I, P>
where I: UnwindSafe, P: UnwindSafe,

§

impl<I, P> UnwindSafe for TakeAnyWhile<I, P>
where I: UnwindSafe, P: UnwindSafe,

§

impl<I, P> UnwindSafe for FilterEntry<I, P>
where I: UnwindSafe, P: UnwindSafe,

§

impl<I, St, F> UnwindSafe for rustmax::itertools::__std_iter::Scan<I, St, F>
where I: UnwindSafe, F: UnwindSafe, St: UnwindSafe,

§

impl<I, T> UnwindSafe for CircularTupleWindows<I, T>
where I: UnwindSafe, T: UnwindSafe,

§

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

§

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

§

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

§

impl<I, T, E> UnwindSafe for FlattenOk<I, T, E>

§

impl<I, T, F> UnwindSafe for MapWith<I, T, F>
where I: UnwindSafe, T: UnwindSafe, F: UnwindSafe,

§

impl<I, U, F> UnwindSafe for rustmax::itertools::__std_iter::FlatMap<I, U, F>

§

impl<I, U, F> UnwindSafe for FoldChunksWith<I, U, F>
where I: UnwindSafe, U: UnwindSafe, F: UnwindSafe,

§

impl<I, U, F> UnwindSafe for FoldWith<I, U, F>
where I: UnwindSafe, U: UnwindSafe, F: UnwindSafe,

§

impl<I, U, F> UnwindSafe for TryFoldWith<I, U, F>
where I: UnwindSafe, <U as Try>::Output: UnwindSafe, F: UnwindSafe,

§

impl<I, U, ID, F> UnwindSafe for rustmax::rayon::iter::TryFold<I, U, ID, F>

§

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

§

impl<I, const N: usize> UnwindSafe for rustmax::itertools::__std_iter::ArrayChunks<I, N>
where I: UnwindSafe, <I as Iterator>::Item: UnwindSafe,

§

impl<IU, B> UnwindSafe for InvertedUInt<IU, B>
where IU: UnwindSafe, B: UnwindSafe,

§

impl<Idx> UnwindSafe for rustmax::core::ops::Range<Idx>
where Idx: UnwindSafe,

§

impl<Idx> UnwindSafe for rustmax::core::ops::RangeFrom<Idx>
where Idx: UnwindSafe,

§

impl<Idx> UnwindSafe for rustmax::core::ops::RangeInclusive<Idx>
where Idx: UnwindSafe,

§

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

§

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

§

impl<Idx> UnwindSafe for rustmax::core::range::Range<Idx>
where Idx: UnwindSafe,

§

impl<Idx> UnwindSafe for rustmax::core::range::RangeFrom<Idx>
where Idx: UnwindSafe,

§

impl<Idx> UnwindSafe for rustmax::core::range::RangeInclusive<Idx>
where Idx: UnwindSafe,

§

impl<In, T, U, E> !UnwindSafe for BoxCloneServiceLayer<In, T, U, E>

§

impl<In, T, U, E> !UnwindSafe for BoxCloneSyncServiceLayer<In, T, U, E>

§

impl<In, T, U, E> !UnwindSafe for BoxLayer<In, T, U, E>

§

impl<Inner, Outer> UnwindSafe for Stack<Inner, Outer>
where Inner: UnwindSafe, Outer: UnwindSafe,

§

impl<Iter> UnwindSafe for IterBridge<Iter>
where Iter: UnwindSafe,

§

impl<K> !UnwindSafe for Failed<K>

§

impl<K> UnwindSafe for rustmax::std::collections::hash_set::IntoIter<K>

§

impl<K, I, F> UnwindSafe for rustmax::itertools::ChunkBy<K, I, F>

§

impl<K, S, Req> !UnwindSafe for ReadyCache<K, S, Req>

§

impl<K, V> UnwindSafe for Change<K, V>
where K: UnwindSafe, V: UnwindSafe,

§

impl<K, V> UnwindSafe for BTreeMapStrategy<K, V>
where K: UnwindSafe, V: UnwindSafe,

§

impl<K, V> UnwindSafe for BTreeMapValueTree<K, V>
where K: UnwindSafe, V: UnwindSafe,

§

impl<K, V> UnwindSafe for HashMapStrategy<K, V>
where K: UnwindSafe, V: UnwindSafe,

§

impl<K, V> UnwindSafe for HashMapValueTree<K, V>
where K: UnwindSafe, V: UnwindSafe,

§

impl<K, V> UnwindSafe for rustmax::rayon::collections::btree_map::IntoIter<K, V>
where K: UnwindSafe, V: UnwindSafe,

§

impl<K, V> UnwindSafe for rustmax::rayon::collections::hash_map::IntoIter<K, V>
where K: UnwindSafe, V: UnwindSafe,

§

impl<K, V> UnwindSafe for rustmax::serde_json::Map<K, V>

§

impl<K, V> UnwindSafe for rustmax::std::collections::hash_map::IntoIter<K, V>

§

impl<K, V> UnwindSafe for rustmax::std::collections::hash_map::IntoKeys<K, V>

§

impl<K, V> UnwindSafe for rustmax::std::collections::hash_map::IntoValues<K, V>

§

impl<K, V> UnwindSafe for rustmax::toml::map::IntoIter<K, V>

§

impl<K, V> UnwindSafe for rustmax::toml::map::Map<K, V>

§

impl<K, V, A> UnwindSafe for rustmax::alloc::collections::btree_map::IntoIter<K, V, A>

§

impl<K, V, A> UnwindSafe for rustmax::alloc::collections::btree_map::IntoKeys<K, V, A>

§

impl<K, V, A> UnwindSafe for rustmax::alloc::collections::btree_map::IntoValues<K, V, A>

§

impl<L> UnwindSafe for ServiceBuilder<L>
where L: UnwindSafe,

§

impl<L, F> UnwindSafe for TapIo<L, F>
where L: UnwindSafe, F: UnwindSafe,

§

impl<L, H, T, S> UnwindSafe for Layered<L, H, T, S>
where L: UnwindSafe, H: UnwindSafe,

§

impl<L, M, S> UnwindSafe for Serve<L, M, S>
where L: UnwindSafe, M: UnwindSafe, S: UnwindSafe,

§

impl<L, M, S, F> UnwindSafe for WithGracefulShutdown<L, M, S, F>

§

impl<L, R> UnwindSafe for rustmax::itertools::Either<L, R>
where L: UnwindSafe, R: UnwindSafe,

§

impl<M, EM, S> UnwindSafe for OutputM<M, EM, S>
where M: UnwindSafe, EM: UnwindSafe, S: UnwindSafe,

§

impl<M, Request> UnwindSafe for IntoService<M, Request>
where M: UnwindSafe, Request: UnwindSafe,

§

impl<M, Target> UnwindSafe for Reconnect<M, Target>
where M: UnwindSafe, Target: UnwindSafe, <M as Service<Target>>::Future: UnwindSafe, <M as Service<Target>>::Response: UnwindSafe, <M as Service<Target>>::Error: UnwindSafe,

§

impl<O, E> UnwindSafe for Fail<O, E>
where O: UnwindSafe, E: UnwindSafe,

§

impl<O, E> UnwindSafe for Success<O, E>
where O: UnwindSafe, E: UnwindSafe,

§

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

§

impl<P> UnwindSafe for RetryLayer<P>
where P: UnwindSafe,

§

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

§

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

§

impl<P, F> UnwindSafe for MapValueParser<P, F>
where P: UnwindSafe, F: UnwindSafe,

§

impl<P, F> UnwindSafe for TryMapValueParser<P, F>
where P: UnwindSafe, F: UnwindSafe,

§

impl<P, S> UnwindSafe for Retry<P, S>
where P: UnwindSafe, S: UnwindSafe,

§

impl<P, S, Request> UnwindSafe for AsyncResponseFuture<P, S, Request>
where S: UnwindSafe, <P as AsyncPredicate<Request>>::Future: UnwindSafe, <S as Service<<P as AsyncPredicate<Request>>::Request>>::Future: UnwindSafe,

§

impl<P, S, Request> UnwindSafe for rustmax::tower::retry::future::ResponseFuture<P, S, Request>
where Request: UnwindSafe, P: UnwindSafe, S: UnwindSafe, <S as Service<Request>>::Future: UnwindSafe, <P as Policy<Request, <S as Service<Request>>::Response, <S as Service<Request>>::Error>>::Future: UnwindSafe,

§

impl<Ptr> UnwindSafe for Pin<Ptr>
where Ptr: UnwindSafe,

§

impl<R> UnwindSafe for rustmax::futures::io::BufReader<R>
where R: UnwindSafe,

§

impl<R> UnwindSafe for rustmax::futures::io::Lines<R>
where R: UnwindSafe,

§

impl<R> UnwindSafe for rustmax::futures::io::Take<R>
where R: UnwindSafe,

§

impl<R> UnwindSafe for BlockRng64<R>

§

impl<R> UnwindSafe for BlockRng<R>

§

impl<R> UnwindSafe for UnwrapErr<R>
where R: UnwindSafe,

§

impl<R> UnwindSafe for IoRead<R>
where R: UnwindSafe,

§

impl<R> UnwindSafe for rustmax::serde_json::Deserializer<R>
where R: UnwindSafe,

§

impl<R> UnwindSafe for rustmax::std::io::BufReader<R>
where R: UnwindSafe + ?Sized,

§

impl<R> UnwindSafe for rustmax::std::io::Bytes<R>
where R: UnwindSafe,

§

impl<R> UnwindSafe for rustmax::tokio::io::BufReader<R>
where R: UnwindSafe,

§

impl<R> UnwindSafe for rustmax::tokio::io::Lines<R>
where R: UnwindSafe,

§

impl<R> UnwindSafe for rustmax::tokio::io::Split<R>
where R: UnwindSafe,

§

impl<R> UnwindSafe for rustmax::tokio::io::Take<R>
where R: UnwindSafe,

§

impl<R> UnwindSafe for ExponentialBackoff<R>
where R: UnwindSafe,

§

impl<R> UnwindSafe for ExponentialBackoffMaker<R>
where R: UnwindSafe,

§

impl<R, F> !UnwindSafe for rustmax::tower::filter::future::ResponseFuture<R, F>

§

impl<R, Rsdr> UnwindSafe for ReseedingRng<R, Rsdr>

§

impl<R, W> UnwindSafe for rustmax::tokio::io::Join<R, W>
where R: UnwindSafe, W: UnwindSafe,

§

impl<RW> UnwindSafe for BufStream<RW>
where RW: UnwindSafe,

§

impl<Req, F> !UnwindSafe for rustmax::tower::buffer::Buffer<Req, F>

§

impl<Request> UnwindSafe for BufferLayer<Request>

§

impl<S = ()> !UnwindSafe for Router<S>

§

impl<S = (), E = Infallible> !UnwindSafe for MethodRouter<S, E>

§

impl<S = DefaultSpawn> !UnwindSafe for ThreadPoolBuilder<S>

§

impl<S> !UnwindSafe for LayeredFuture<S>

§

impl<S> !UnwindSafe for SplitStream<S>

§

impl<S> !UnwindSafe for FlattenValueTree<S>

§

impl<S> !UnwindSafe for LazyValueTree<S>

§

impl<S> UnwindSafe for Host<S>
where S: UnwindSafe,

§

impl<S> UnwindSafe for State<S>
where S: UnwindSafe,

§

impl<S> UnwindSafe for Sse<S>
where S: UnwindSafe,

§

impl<S> UnwindSafe for IntoMakeServiceFuture<S>
where S: UnwindSafe,

§

impl<S> UnwindSafe for IntoMakeService<S>
where S: UnwindSafe,

§

impl<S> UnwindSafe for BlockingStream<S>
where S: UnwindSafe,

§

impl<S> UnwindSafe for rustmax::prelude::stream::PollImmediate<S>
where S: UnwindSafe,

§

impl<S> UnwindSafe for rustmax::proptest::strategy::Flatten<S>
where S: UnwindSafe,

§

impl<S> UnwindSafe for IndFlatten<S>
where S: UnwindSafe,

§

impl<S> UnwindSafe for Shuffle<S>
where S: UnwindSafe,

§

impl<S> UnwindSafe for LoadShed<S>
where S: UnwindSafe,

§

impl<S> UnwindSafe for SharedFuture<S>
where S: UnwindSafe,

§

impl<S> UnwindSafe for rustmax::tower::make::Shared<S>
where S: UnwindSafe,

§

impl<S> UnwindSafe for SpawnReady<S>
where S: UnwindSafe,

§

impl<S, B> UnwindSafe for WalkTree<S, B>
where S: UnwindSafe, B: UnwindSafe,

§

impl<S, B> UnwindSafe for WalkTreePostfix<S, B>
where S: UnwindSafe, B: UnwindSafe,

§

impl<S, B> UnwindSafe for WalkTreePrefix<S, B>
where S: UnwindSafe, B: UnwindSafe,

§

impl<S, C> UnwindSafe for IntoMakeServiceWithConnectInfo<S, C>
where S: UnwindSafe,

§

impl<S, C> UnwindSafe for rustmax::axum::extract::connect_info::ResponseFuture<S, C>
where S: UnwindSafe, C: UnwindSafe,

§

impl<S, C> UnwindSafe for PeakEwma<S, C>
where S: UnwindSafe, C: UnwindSafe,

§

impl<S, C> UnwindSafe for PendingRequests<S, C>
where S: UnwindSafe, C: UnwindSafe,

§

impl<S, F> UnwindSafe for rustmax::proptest::strategy::statics::Filter<S, F>
where S: UnwindSafe, F: UnwindSafe,

§

impl<S, F> UnwindSafe for rustmax::proptest::strategy::statics::Map<S, F>
where S: UnwindSafe, F: UnwindSafe,

§

impl<S, F> UnwindSafe for rustmax::proptest::strategy::Filter<S, F>

§

impl<S, F> UnwindSafe for rustmax::proptest::strategy::FilterMap<S, F>

§

impl<S, F> UnwindSafe for IndFlattenMap<S, F>

§

impl<S, F> UnwindSafe for rustmax::proptest::strategy::Map<S, F>

§

impl<S, F> UnwindSafe for Perturb<S, F>

§

impl<S, F> UnwindSafe for PerturbValueTree<S, F>

§

impl<S, F> UnwindSafe for rustmax::tower::util::AndThen<S, F>
where S: UnwindSafe, F: UnwindSafe,

§

impl<S, F> UnwindSafe for rustmax::tower::util::MapErr<S, F>
where S: UnwindSafe, F: UnwindSafe,

§

impl<S, F> UnwindSafe for MapFuture<S, F>
where S: UnwindSafe, F: UnwindSafe,

§

impl<S, F> UnwindSafe for rustmax::tower::util::MapRequest<S, F>
where S: UnwindSafe, F: UnwindSafe,

§

impl<S, F> UnwindSafe for rustmax::tower::util::MapResponse<S, F>
where S: UnwindSafe, F: UnwindSafe,

§

impl<S, F> UnwindSafe for MapResult<S, F>
where S: UnwindSafe, F: UnwindSafe,

§

impl<S, F> UnwindSafe for rustmax::tower::util::Then<S, F>
where S: UnwindSafe, F: UnwindSafe,

§

impl<S, F, Req> UnwindSafe for Steer<S, F, Req>
where F: UnwindSafe, Req: UnwindSafe, S: UnwindSafe,

§

impl<S, F, T> UnwindSafe for HandleError<S, F, T>
where S: UnwindSafe, F: UnwindSafe,

§

impl<S, Item> !UnwindSafe for SplitSink<S, Item>

§

impl<S, O> UnwindSafe for rustmax::proptest::strategy::MapInto<S, O>
where S: UnwindSafe, O: UnwindSafe,

§

impl<S, P> UnwindSafe for Hedge<S, P>
where P: UnwindSafe, S: UnwindSafe,

§

impl<S, Req> UnwindSafe for MakeBalance<S, Req>
where S: UnwindSafe,

§

impl<S, Req> UnwindSafe for Oneshot<S, Req>
where S: UnwindSafe, <S as Service<Req>>::Future: UnwindSafe, Req: UnwindSafe,

§

impl<S, Request> UnwindSafe for Future<S, Request>
where <S as Service<Request>>::Future: UnwindSafe,

§

impl<S, T> UnwindSafe for AddExtension<S, T>
where S: UnwindSafe, T: UnwindSafe,

§

impl<S, T> UnwindSafe for UniformArrayStrategy<S, T>
where S: UnwindSafe, T: UnwindSafe,

§

impl<Si1, Si2> UnwindSafe for Fanout<Si1, Si2>
where Si1: UnwindSafe, Si2: UnwindSafe,

§

impl<Si, F> UnwindSafe for SinkMapErr<Si, F>
where Si: UnwindSafe, F: UnwindSafe,

§

impl<Si, Item> UnwindSafe for rustmax::prelude::sink::Buffer<Si, Item>
where Si: UnwindSafe, Item: UnwindSafe,

§

impl<Si, Item, E> UnwindSafe for SinkErrInto<Si, Item, E>
where Si: UnwindSafe,

§

impl<Si, Item, U, Fut, F> UnwindSafe for With<Si, Item, U, Fut, F>
where Si: UnwindSafe, F: UnwindSafe, Fut: UnwindSafe,

§

impl<Si, Item, U, St, F> UnwindSafe for WithFlatMap<Si, Item, U, St, F>
where Si: UnwindSafe, F: UnwindSafe, St: UnwindSafe, Item: UnwindSafe,

§

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

§

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

§

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

§

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

§

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

§

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

§

impl<St1, St2> UnwindSafe for rustmax::prelude::stream::Chain<St1, St2>
where St2: UnwindSafe, St1: UnwindSafe,

§

impl<St1, St2> UnwindSafe for rustmax::prelude::stream::Select<St1, St2>
where St1: UnwindSafe, St2: UnwindSafe,

§

impl<St1, St2> UnwindSafe for rustmax::prelude::stream::Zip<St1, St2>
where St1: UnwindSafe, St2: UnwindSafe, <St1 as Stream>::Item: UnwindSafe, <St2 as Stream>::Item: UnwindSafe,

§

impl<St1, St2, Clos, State> UnwindSafe for SelectWithStrategy<St1, St2, Clos, State>
where St1: UnwindSafe, St2: UnwindSafe, State: UnwindSafe, Clos: UnwindSafe,

§

impl<St> !UnwindSafe for rustmax::prelude::stream::select_all::IntoIter<St>

§

impl<St> !UnwindSafe for BufferUnordered<St>

§

impl<St> !UnwindSafe for Buffered<St>

§

impl<St> !UnwindSafe for rustmax::prelude::stream::SelectAll<St>

§

impl<St> !UnwindSafe for TryBufferUnordered<St>

§

impl<St> !UnwindSafe for TryBuffered<St>

§

impl<St> !UnwindSafe for TryFlattenUnordered<St>

§

impl<St> UnwindSafe for rustmax::prelude::stream::CatchUnwind<St>
where St: UnwindSafe,

§

impl<St> UnwindSafe for rustmax::prelude::stream::Chunks<St>
where St: UnwindSafe, <St as Stream>::Item: UnwindSafe,

§

impl<St> UnwindSafe for Concat<St>
where St: UnwindSafe, <St as Stream>::Item: UnwindSafe,

§

impl<St> UnwindSafe for rustmax::prelude::stream::Count<St>
where St: UnwindSafe,

§

impl<St> UnwindSafe for rustmax::prelude::stream::Cycle<St>
where St: UnwindSafe,

§

impl<St> UnwindSafe for rustmax::prelude::stream::Enumerate<St>
where St: UnwindSafe,

§

impl<St> UnwindSafe for rustmax::prelude::stream::Flatten<St>
where St: UnwindSafe, <St as Stream>::Item: UnwindSafe,

§

impl<St> UnwindSafe for rustmax::prelude::stream::Fuse<St>
where St: UnwindSafe,

§

impl<St> UnwindSafe for IntoAsyncRead<St>
where St: UnwindSafe, <St as TryStream>::Ok: UnwindSafe,

§

impl<St> UnwindSafe for rustmax::prelude::stream::IntoStream<St>
where St: UnwindSafe,

§

impl<St> UnwindSafe for rustmax::prelude::stream::Peekable<St>
where St: UnwindSafe, <St as Stream>::Item: UnwindSafe,

§

impl<St> UnwindSafe for ReadyChunks<St>
where St: UnwindSafe,

§

impl<St> UnwindSafe for rustmax::prelude::stream::Skip<St>
where St: UnwindSafe,

§

impl<St> UnwindSafe for StreamFuture<St>
where St: UnwindSafe,

§

impl<St> UnwindSafe for rustmax::prelude::stream::Take<St>
where St: UnwindSafe,

§

impl<St> UnwindSafe for TryChunks<St>
where St: UnwindSafe, <St as TryStream>::Ok: UnwindSafe,

§

impl<St> UnwindSafe for TryConcat<St>
where St: UnwindSafe, <St as TryStream>::Ok: UnwindSafe,

§

impl<St> UnwindSafe for rustmax::prelude::stream::TryFlatten<St>
where St: UnwindSafe, <St as TryStream>::Ok: UnwindSafe,

§

impl<St> UnwindSafe for TryReadyChunks<St>
where St: UnwindSafe,

§

impl<St, C> UnwindSafe for Collect<St, C>
where St: UnwindSafe, C: UnwindSafe,

§

impl<St, C> UnwindSafe for TryCollect<St, C>
where St: UnwindSafe, C: UnwindSafe,

§

impl<St, E> UnwindSafe for rustmax::prelude::stream::ErrInto<St, E>
where St: UnwindSafe,

§

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

§

impl<St, F> UnwindSafe for rustmax::itertools::Unfold<St, F>
where F: UnwindSafe, St: UnwindSafe,

§

impl<St, F> UnwindSafe for rustmax::prelude::stream::Inspect<St, F>
where St: UnwindSafe, F: UnwindSafe,

§

impl<St, F> UnwindSafe for rustmax::prelude::stream::InspectErr<St, F>
where St: UnwindSafe, F: UnwindSafe,

§

impl<St, F> UnwindSafe for rustmax::prelude::stream::InspectOk<St, F>
where St: UnwindSafe, F: UnwindSafe,

§

impl<St, F> UnwindSafe for rustmax::prelude::stream::Map<St, F>
where St: UnwindSafe, F: UnwindSafe,

§

impl<St, F> UnwindSafe for rustmax::prelude::stream::MapErr<St, F>
where St: UnwindSafe, F: UnwindSafe,

§

impl<St, F> UnwindSafe for rustmax::prelude::stream::MapOk<St, F>
where St: UnwindSafe, F: UnwindSafe,

§

impl<St, FromA, FromB> UnwindSafe for Unzip<St, FromA, FromB>
where St: UnwindSafe, FromA: UnwindSafe, FromB: UnwindSafe,

§

impl<St, Fut> UnwindSafe for rustmax::prelude::stream::TakeUntil<St, Fut>
where St: UnwindSafe, Fut: UnwindSafe, <Fut as Future>::Output: UnwindSafe,

§

impl<St, Fut, F> !UnwindSafe for ForEachConcurrent<St, Fut, F>

§

impl<St, Fut, F> !UnwindSafe for TryForEachConcurrent<St, Fut, F>

§

impl<St, Fut, F> UnwindSafe for All<St, Fut, F>
where St: UnwindSafe, F: UnwindSafe, Fut: UnwindSafe,

§

impl<St, Fut, F> UnwindSafe for rustmax::prelude::stream::AndThen<St, Fut, F>
where St: UnwindSafe, F: UnwindSafe, Fut: UnwindSafe,

§

impl<St, Fut, F> UnwindSafe for rustmax::prelude::stream::Any<St, Fut, F>
where St: UnwindSafe, F: UnwindSafe, Fut: UnwindSafe,

§

impl<St, Fut, F> UnwindSafe for rustmax::prelude::stream::Filter<St, Fut, F>
where St: UnwindSafe, F: UnwindSafe, Fut: UnwindSafe, <St as Stream>::Item: UnwindSafe,

§

impl<St, Fut, F> UnwindSafe for rustmax::prelude::stream::FilterMap<St, Fut, F>
where St: UnwindSafe, F: UnwindSafe, Fut: UnwindSafe,

§

impl<St, Fut, F> UnwindSafe for ForEach<St, Fut, F>
where St: UnwindSafe, F: UnwindSafe, Fut: UnwindSafe,

§

impl<St, Fut, F> UnwindSafe for rustmax::prelude::stream::OrElse<St, Fut, F>
where St: UnwindSafe, F: UnwindSafe, Fut: UnwindSafe,

§

impl<St, Fut, F> UnwindSafe for rustmax::prelude::stream::SkipWhile<St, Fut, F>
where St: UnwindSafe, F: UnwindSafe, Fut: UnwindSafe, <St as Stream>::Item: UnwindSafe,

§

impl<St, Fut, F> UnwindSafe for rustmax::prelude::stream::TakeWhile<St, Fut, F>
where St: UnwindSafe, F: UnwindSafe, Fut: UnwindSafe, <St as Stream>::Item: UnwindSafe,

§

impl<St, Fut, F> UnwindSafe for rustmax::prelude::stream::Then<St, Fut, F>
where St: UnwindSafe, F: UnwindSafe, Fut: UnwindSafe,

§

impl<St, Fut, F> UnwindSafe for TryAll<St, Fut, F>
where St: UnwindSafe, F: UnwindSafe, Fut: UnwindSafe,

§

impl<St, Fut, F> UnwindSafe for TryAny<St, Fut, F>
where St: UnwindSafe, F: UnwindSafe, Fut: UnwindSafe,

§

impl<St, Fut, F> UnwindSafe for TryFilter<St, Fut, F>
where St: UnwindSafe, F: UnwindSafe, Fut: UnwindSafe, <St as TryStream>::Ok: UnwindSafe,

§

impl<St, Fut, F> UnwindSafe for TryFilterMap<St, Fut, F>
where St: UnwindSafe, F: UnwindSafe, Fut: UnwindSafe,

§

impl<St, Fut, F> UnwindSafe for TryForEach<St, Fut, F>
where St: UnwindSafe, F: UnwindSafe, Fut: UnwindSafe,

§

impl<St, Fut, F> UnwindSafe for TrySkipWhile<St, Fut, F>
where St: UnwindSafe, F: UnwindSafe, Fut: UnwindSafe, <St as TryStream>::Ok: UnwindSafe,

§

impl<St, Fut, F> UnwindSafe for TryTakeWhile<St, Fut, F>
where St: UnwindSafe, F: UnwindSafe, Fut: UnwindSafe, <St as TryStream>::Ok: UnwindSafe,

§

impl<St, Fut, T, F> UnwindSafe for rustmax::prelude::stream::Fold<St, Fut, T, F>
where St: UnwindSafe, F: UnwindSafe, T: UnwindSafe, Fut: UnwindSafe,

§

impl<St, Fut, T, F> UnwindSafe for rustmax::prelude::stream::TryFold<St, Fut, T, F>
where St: UnwindSafe, F: UnwindSafe, T: UnwindSafe, Fut: UnwindSafe,

§

impl<St, S, Fut, F> UnwindSafe for rustmax::prelude::stream::Scan<St, S, Fut, F>
where St: UnwindSafe, Fut: UnwindSafe, S: UnwindSafe, F: UnwindSafe,

§

impl<St, Si> UnwindSafe for Forward<St, Si>
where Si: UnwindSafe, St: UnwindSafe, <St as TryStream>::Ok: UnwindSafe,

§

impl<St, U, F> !UnwindSafe for FlatMapUnordered<St, U, F>

§

impl<St, U, F> UnwindSafe for rustmax::prelude::stream::FlatMap<St, U, F>
where St: UnwindSafe, F: UnwindSafe, U: UnwindSafe,

§

impl<Svc, S> !UnwindSafe for CallAll<Svc, S>

§

impl<Svc, S> !UnwindSafe for CallAllUnordered<Svc, S>

§

impl<T> !UnwindSafe for rustmax::clap::parser::Values<T>

§

impl<T> !UnwindSafe for Injector<T>

§

impl<T> !UnwindSafe for rustmax::futures::channel::mpsc::Receiver<T>

§

impl<T> !UnwindSafe for rustmax::futures::channel::mpsc::Sender<T>

§

impl<T> !UnwindSafe for rustmax::futures::channel::mpsc::UnboundedReceiver<T>

§

impl<T> !UnwindSafe for rustmax::futures::channel::mpsc::UnboundedSender<T>

§

impl<T> !UnwindSafe for rustmax::futures::channel::oneshot::Receiver<T>

§

impl<T> !UnwindSafe for rustmax::futures::channel::oneshot::Sender<T>

§

impl<T> !UnwindSafe for rustmax::futures::io::ReadHalf<T>

§

impl<T> !UnwindSafe for rustmax::futures::io::ReuniteError<T>

§

impl<T> !UnwindSafe for rustmax::futures::io::WriteHalf<T>

§

impl<T> !UnwindSafe for rustmax::futures::lock::OwnedMutexGuard<T>

§

impl<T> !UnwindSafe for OwnedMutexLockFuture<T>

§

impl<T> !UnwindSafe for rustmax::http::Request<T>

§

impl<T> !UnwindSafe for rustmax::http::Response<T>

§

impl<T> !UnwindSafe for rustmax::hyper::client::conn::TrySendError<T>

§

impl<T> !UnwindSafe for Abortable<T>

§

impl<T> !UnwindSafe for RemoteHandle<T>

§

impl<T> !UnwindSafe for FuturesOrdered<T>

§

impl<T> !UnwindSafe for OptionValueTree<T>

§

impl<T> !UnwindSafe for BoxedStrategy<T>

§

impl<T> !UnwindSafe for SBoxedStrategy<T>

§

impl<T> !UnwindSafe for UnionValueTree<T>

§

impl<T> !UnwindSafe for RegexGeneratorStrategy<T>

§

impl<T> !UnwindSafe for RegexGeneratorValueTree<T>

§

impl<T> !UnwindSafe for rustmax::std::thread::JoinHandle<T>

§

impl<T> !UnwindSafe for AsyncFd<T>

§

impl<T> !UnwindSafe for AsyncFdTryNewError<T>

§

impl<T> !UnwindSafe for rustmax::tokio::sync::broadcast::Receiver<T>

§

impl<T> !UnwindSafe for rustmax::tokio::sync::broadcast::Sender<T>

§

impl<T> !UnwindSafe for rustmax::tokio::sync::broadcast::WeakSender<T>

§

impl<T> !UnwindSafe for rustmax::tokio::sync::oneshot::Receiver<T>

§

impl<T> !UnwindSafe for rustmax::tokio::sync::oneshot::Sender<T>

§

impl<T> !UnwindSafe for rustmax::tokio::sync::Mutex<T>

§

impl<T> !UnwindSafe for rustmax::tokio::sync::OnceCell<T>

§

impl<T> !UnwindSafe for rustmax::tokio::sync::OwnedMutexGuard<T>

§

impl<T> !UnwindSafe for OwnedRwLockWriteGuard<T>

§

impl<T> !UnwindSafe for rustmax::tokio::sync::RwLock<T>

§

impl<T> !UnwindSafe for rustmax::tokio::sync::watch::Receiver<T>

§

impl<T> !UnwindSafe for rustmax::tokio::sync::watch::Sender<T>

§

impl<T> !UnwindSafe for JoinSet<T>

§

impl<T> !UnwindSafe for rustmax::tokio::time::Timeout<T>

§

impl<T> !UnwindSafe for rustmax::tower::buffer::future::ResponseFuture<T>

§

impl<T> !UnwindSafe for rustmax::tower::limit::concurrency::future::ResponseFuture<T>

§

impl<T> !UnwindSafe for ConcurrencyLimit<T>

§

impl<T> !UnwindSafe for RateLimit<T>

§

impl<T> !UnwindSafe for rustmax::tower::timeout::future::ResponseFuture<T>

§

impl<T> UnwindSafe for LocalResult<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for Resettable<T>
where T: UnwindSafe,

§

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

§

impl<T> UnwindSafe for rustmax::crossbeam::channel::SendTimeoutError<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::crossbeam::channel::TrySendError<T>
where T: UnwindSafe,

§

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

§

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

§

impl<T> UnwindSafe for FoldWhile<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for MinMaxResult<T>
where T: UnwindSafe,

§

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

§

impl<T> UnwindSafe for TestError<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::std::sync::TryLockError<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::std::sync::mpmc::SendTimeoutError<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::std::sync::mpmc::TrySendError<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for SetError<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::tokio::sync::mpsc::error::SendTimeoutError<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::tokio::sync::mpsc::error::TrySendError<T>
where T: UnwindSafe,

§

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

§

impl<T> UnwindSafe for MockConnectInfo<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for ConnectInfo<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::axum::extract::Path<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for Query<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for Html<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for Extension<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for Form<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for Json<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::bytes::buf::IntoIter<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for Limit<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::bytes::buf::Take<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for RangedI64ValueParser<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for RangedU64ValueParser<T>
where T: UnwindSafe,

§

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

§

impl<T> UnwindSafe for rustmax::core::cell::OnceCell<T>
where T: UnwindSafe,

§

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

§

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

§

impl<T> UnwindSafe for UnsafeCell<T>
where T: UnwindSafe + ?Sized,

§

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

§

impl<T> UnwindSafe for rustmax::core::future::Pending<T>

§

impl<T> UnwindSafe for rustmax::core::future::Ready<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for PhantomContravariant<T>
where T: ?Sized,

§

impl<T> UnwindSafe for PhantomCovariant<T>
where T: ?Sized,

§

impl<T> UnwindSafe for PhantomData<T>
where T: UnwindSafe + ?Sized,

§

impl<T> UnwindSafe for PhantomInvariant<T>
where T: ?Sized,

§

impl<T> UnwindSafe for Discriminant<T>

§

impl<T> UnwindSafe for ManuallyDrop<T>
where T: UnwindSafe + ?Sized,

§

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

§

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

§

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

§

impl<T> UnwindSafe for UnsafePinned<T>
where T: UnwindSafe + ?Sized,

§

impl<T> UnwindSafe for rustmax::core::result::IntoIter<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for AtomicPtr<T>
where T: RefUnwindSafe,

§

impl<T> UnwindSafe for Exclusive<T>
where T: UnwindSafe + ?Sized,

§

impl<T> UnwindSafe for rustmax::crossbeam::channel::IntoIter<T>

§

impl<T> UnwindSafe for rustmax::crossbeam::channel::SendError<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for Stealer<T>
where T: RefUnwindSafe,

§

impl<T> UnwindSafe for Worker<T>
where T: RefUnwindSafe,

§

impl<T> UnwindSafe for Atomic<T>
where T: RefUnwindSafe + ?Sized,

§

impl<T> UnwindSafe for Owned<T>
where T: UnwindSafe + ?Sized,

§

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

§

impl<T> UnwindSafe for CxxVector<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for SharedPtr<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for UniquePtr<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for WeakPtr<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for TryFromReprError<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for TryIntoError<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for TryUnwrapError<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::futures::channel::mpsc::TrySendError<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for AllowStdIo<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::futures::io::Cursor<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for Window<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::futures::lock::Mutex<T>
where T: UnwindSafe + ?Sized,

§

impl<T> UnwindSafe for rustmax::http::header::IntoIter<T>

§

impl<T> UnwindSafe for HeaderMap<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for Port<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::hyper::body::Frame<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::hyper::client::conn::http1::Parts<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::hyper::upgrade::Parts<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::itertools::__std_iter::Empty<T>

§

impl<T> UnwindSafe for rustmax::itertools::__std_iter::Once<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::itertools::__std_iter::Rev<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for TupleBuffer<T>
where <T as TupleCollect>::Buffer: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::itertools::Zip<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for Choice<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for TryFromBigIntError<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::prelude::future::Pending<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::prelude::future::PollImmediate<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::prelude::future::Ready<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::prelude::sink::Drain<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::prelude::stream::Empty<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::prelude::stream::Pending<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::prelude::stream::Repeat<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for ArrayValueTree<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for BitSetStrategy<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for BitSetValueTree<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for SampledBitSetStrategy<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for BTreeSetStrategy<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for BTreeSetValueTree<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for BinaryHeapStrategy<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for BinaryHeapValueTree<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for HashSetStrategy<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for HashSetValueTree<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for LinkedListStrategy<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for LinkedListValueTree<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for VecDequeStrategy<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for VecDequeValueTree<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for VecStrategy<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for VecValueTree<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for OptionStrategy<T>

§

impl<T> UnwindSafe for rustmax::proptest::sample::Select<T>
where T: RefUnwindSafe,

§

impl<T> UnwindSafe for SelectValueTree<T>
where T: RefUnwindSafe,

§

impl<T> UnwindSafe for Subsequence<T>
where T: RefUnwindSafe,

§

impl<T> UnwindSafe for SubsequenceValueTree<T>
where T: RefUnwindSafe,

§

impl<T> UnwindSafe for rustmax::proptest::strategy::Fuse<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for Just<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for NoShrink<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for TupleUnion<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for TupleUnionValueTree<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::proptest::strategy::Union<T>
where T: RefUnwindSafe,

§

impl<T> UnwindSafe for TupleValueTree<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::rayon::collections::binary_heap::IntoIter<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::rayon::collections::btree_set::IntoIter<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::rayon::collections::hash_set::IntoIter<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::rayon::collections::linked_list::IntoIter<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::rayon::collections::vec_deque::IntoIter<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::rayon::iter::Empty<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for MultiZip<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::rayon::iter::Once<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::rayon::iter::Repeat<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::rayon::iter::RepeatN<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::rayon::option::IntoIter<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::rayon::range::Iter<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::rayon::range_inclusive::Iter<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::rayon::result::IntoIter<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::rayon::vec::IntoIter<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for CoreWrapper<T>

§

impl<T> UnwindSafe for RtVariableCoreWrapper<T>

§

impl<T> UnwindSafe for XofReaderCoreWrapper<T>

§

impl<T> UnwindSafe for rustmax::std::io::Cursor<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::std::io::Take<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::std::sync::mpmc::IntoIter<T>

§

impl<T> UnwindSafe for rustmax::std::sync::mpmc::SendError<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::std::sync::mpsc::IntoIter<T>

§

impl<T> UnwindSafe for rustmax::std::sync::mpsc::Receiver<T>

§

impl<T> UnwindSafe for rustmax::std::sync::mpsc::Sender<T>

§

impl<T> UnwindSafe for SyncSender<T>

§

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

§

impl<T> UnwindSafe for rustmax::std::thread::LocalKey<T>

§

impl<T> UnwindSafe for rustmax::syn::punctuated::IntoIter<T>

§

impl<T> UnwindSafe for rustmax::tokio::io::ReadHalf<T>

§

impl<T> UnwindSafe for rustmax::tokio::io::WriteHalf<T>

§

impl<T> UnwindSafe for rustmax::tokio::sync::broadcast::error::SendError<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::tokio::sync::mpsc::error::SendError<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for OwnedPermit<T>

§

impl<T> UnwindSafe for rustmax::tokio::sync::mpsc::Receiver<T>

§

impl<T> UnwindSafe for rustmax::tokio::sync::mpsc::Sender<T>

§

impl<T> UnwindSafe for rustmax::tokio::sync::mpsc::UnboundedReceiver<T>

§

impl<T> UnwindSafe for rustmax::tokio::sync::mpsc::UnboundedSender<T>

§

impl<T> UnwindSafe for rustmax::tokio::sync::mpsc::WeakSender<T>

§

impl<T> UnwindSafe for WeakUnboundedSender<T>

§

impl<T> UnwindSafe for rustmax::tokio::sync::watch::error::SendError<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::tokio::task::LocalKey<T>

§

impl<T> UnwindSafe for Spanned<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for ServiceList<T>

§

impl<T> UnwindSafe for rustmax::tower::timeout::Timeout<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for rustmax::tower::util::future::optional::ResponseFuture<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for Optional<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for ServiceFn<T>
where T: UnwindSafe,

§

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

§

impl<T> UnwindSafe for Storage<T>
where T: UnwindSafe,

§

impl<T> UnwindSafe for Wrapper<T>
where T: UnwindSafe,

§

impl<T, A = Global> !UnwindSafe for UniqueRc<T, A>

§

impl<T, A = Global> !UnwindSafe for rustmax::alloc::rc::Weak<T, A>

§

impl<T, A> UnwindSafe for rustmax::alloc::collections::binary_heap::IntoIter<T, A>

§

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

§

impl<T, A> UnwindSafe for rustmax::alloc::collections::btree_set::IntoIter<T, A>

§

impl<T, A> UnwindSafe for rustmax::alloc::collections::linked_list::IntoIter<T, A>

§

impl<T, A> UnwindSafe for BTreeSet<T, A>

§

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

§

impl<T, A> UnwindSafe for LinkedList<T, A>

§

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

§

impl<T, A> UnwindSafe for rustmax::alloc::collections::vec_deque::IntoIter<T, A>
where A: UnwindSafe, T: UnwindSafe,

§

impl<T, A> UnwindSafe for UniqueArc<T, A>

§

impl<T, A> UnwindSafe for rustmax::alloc::sync::Weak<T, A>
where A: UnwindSafe, T: RefUnwindSafe + ?Sized,

§

impl<T, A> UnwindSafe for rustmax::prelude::Box<T, A>
where A: UnwindSafe, T: UnwindSafe + ?Sized,

§

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

§

impl<T, A> UnwindSafe for rustmax::prelude::vec::IntoIter<T, A>

§

impl<T, B> !UnwindSafe for rustmax::hyper::client::conn::http1::Connection<T, B>

§

impl<T, B, E> !UnwindSafe for rustmax::hyper::client::conn::http2::Connection<T, B, E>

§

impl<T, D> UnwindSafe for Storage<T, D>
where T: UnwindSafe, D: UnwindSafe,

§

impl<T, E> !UnwindSafe for MaybeErrValueTree<T, E>

§

impl<T, E> !UnwindSafe for MaybeOkValueTree<T, E>

§

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

§

impl<T, E> UnwindSafe for Tag<T, E>
where T: UnwindSafe, E: UnwindSafe,

§

impl<T, E> UnwindSafe for TagNoCase<T, E>
where T: UnwindSafe, E: UnwindSafe,

§

impl<T, E> UnwindSafe for TakeUntil1<T, E>
where T: UnwindSafe, E: UnwindSafe,

§

impl<T, E> UnwindSafe for rustmax::nom::bytes::TakeUntil<T, E>
where T: UnwindSafe, E: UnwindSafe,

§

impl<T, E> UnwindSafe for TryChunksError<T, E>
where E: UnwindSafe, T: UnwindSafe,

§

impl<T, E> UnwindSafe for TryReadyChunksError<T, E>
where E: UnwindSafe, T: UnwindSafe,

§

impl<T, E> UnwindSafe for MaybeErr<T, E>

§

impl<T, E> UnwindSafe for MaybeOk<T, E>

§

impl<T, E, S> UnwindSafe for FromExtractor<T, E, S>
where T: UnwindSafe, S: UnwindSafe,

§

impl<T, Error> UnwindSafe for Permutation<T, Error>
where T: UnwindSafe, Error: UnwindSafe,

§

impl<T, F> !UnwindSafe for Recursive<T, F>

§

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

§

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

§

impl<T, F> UnwindSafe for AlwaysReady<T, F>
where F: UnwindSafe,

§

impl<T, F> UnwindSafe for LazyJust<T, F>
where F: UnwindSafe,

§

impl<T, F> UnwindSafe for TaskLocalFuture<T, F>
where T: UnwindSafe, F: UnwindSafe,

§

impl<T, F, Fut> UnwindSafe for TryUnfold<T, F, Fut>
where F: UnwindSafe, T: UnwindSafe, Fut: UnwindSafe,

§

impl<T, F, Fut> UnwindSafe for rustmax::prelude::stream::Unfold<T, F, Fut>
where F: UnwindSafe, T: UnwindSafe, Fut: UnwindSafe,

§

impl<T, F, R> UnwindSafe for rustmax::prelude::sink::Unfold<T, F, R>
where F: UnwindSafe, T: UnwindSafe, R: UnwindSafe,

§

impl<T, Item> !UnwindSafe for rustmax::prelude::stream::ReuniteError<T, Item>

§

impl<T, M> UnwindSafe for Constant<T, M>
where T: UnwindSafe, M: UnwindSafe,

§

impl<T, N> UnwindSafe for GenericArrayIter<T, N>
where <N as ArrayLength<T>>::ArrayType: UnwindSafe,

§

impl<T, OutSize, O> UnwindSafe for CtVariableCoreWrapper<T, OutSize, O>
where T: UnwindSafe, OutSize: UnwindSafe, O: UnwindSafe,

§

impl<T, P> UnwindSafe for rustmax::syn::punctuated::Pair<T, P>
where T: UnwindSafe, P: UnwindSafe,

§

impl<T, P> UnwindSafe for IntoPairs<T, P>

§

impl<T, P> UnwindSafe for Punctuated<T, P>
where T: UnwindSafe, P: UnwindSafe,

§

impl<T, Request> UnwindSafe for ReadyOneshot<T, Request>
where T: UnwindSafe,

§

impl<T, S> !UnwindSafe for rustmax::hyper::server::conn::http1::Connection<T, S>

§

impl<T, S> !UnwindSafe for UpgradeableConnection<T, S>

§

impl<T, S> UnwindSafe for AHashSet<T, S>
where S: UnwindSafe, T: UnwindSafe,

§

impl<T, S> UnwindSafe for rustmax::hyper::server::conn::http1::Parts<T, S>
where T: UnwindSafe, S: UnwindSafe,

§

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

§

impl<T, S, E> !UnwindSafe for rustmax::hyper::server::conn::http2::Connection<T, S, E>

§

impl<T, U = T> !UnwindSafe for OwnedMappedMutexGuard<T, U>

§

impl<T, U = T> !UnwindSafe for OwnedRwLockMappedWriteGuard<T, U>

§

impl<T, U = T> !UnwindSafe for OwnedRwLockReadGuard<T, U>

§

impl<T, U> UnwindSafe for rustmax::bytes::buf::Chain<T, U>
where T: UnwindSafe, U: UnwindSafe,

§

impl<T, U> UnwindSafe for rustmax::futures::io::Chain<T, U>
where T: UnwindSafe, U: UnwindSafe,

§

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

§

impl<T, U> UnwindSafe for GenericArray<T, U>
where <U as ArrayLength<T>>::ArrayType: UnwindSafe,

§

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

§

impl<T, U> UnwindSafe for AsyncFilter<T, U>
where T: UnwindSafe, U: UnwindSafe,

§

impl<T, U> UnwindSafe for rustmax::tower::filter::Filter<T, U>
where T: UnwindSafe, U: UnwindSafe,

§

impl<T, U, E> !UnwindSafe for BoxCloneService<T, U, E>

§

impl<T, U, E> !UnwindSafe for BoxCloneSyncService<T, U, E>

§

impl<T, U, E> !UnwindSafe for BoxService<T, U, E>

§

impl<T, U, E> !UnwindSafe for UnsyncBoxService<T, U, E>

§

impl<T, const N: usize> UnwindSafe for rustmax::core::array::IntoIter<T, N>
where T: UnwindSafe,

§

impl<T, const N: usize> UnwindSafe for Mask<T, N>
where T: UnwindSafe,

§

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

§

impl<T, const N: usize> UnwindSafe for rustmax::rayon::array::IntoIter<T, N>
where T: UnwindSafe,

§

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

§

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

§

impl<Tz> UnwindSafe for rustmax::chrono::Date<Tz>
where <Tz as TimeZone>::Offset: UnwindSafe,

§

impl<Tz> UnwindSafe for rustmax::chrono::DateTime<Tz>
where <Tz as TimeZone>::Offset: UnwindSafe,

§

impl<U> UnwindSafe for NInt<U>
where U: UnwindSafe,

§

impl<U> UnwindSafe for PInt<U>
where U: UnwindSafe,

§

impl<U> UnwindSafe for AsyncFilterLayer<U>
where U: UnwindSafe,

§

impl<U> UnwindSafe for FilterLayer<U>
where U: UnwindSafe,

§

impl<U, B> UnwindSafe for UInt<U, B>
where U: UnwindSafe, B: UnwindSafe,

§

impl<V> UnwindSafe for ShuffleValueTree<V>
where V: UnwindSafe,

§

impl<V, A> UnwindSafe for TArr<V, A>
where V: UnwindSafe, A: UnwindSafe,

§

impl<V, F, O> UnwindSafe for FilterMapValueTree<V, F, O>

§

impl<W> !UnwindSafe for IntoInnerError<W>

§

impl<W> UnwindSafe for rustmax::futures::io::BufWriter<W>
where W: UnwindSafe,

§

impl<W> UnwindSafe for rustmax::futures::io::LineWriter<W>
where W: UnwindSafe,

§

impl<W> UnwindSafe for StdFmtWrite<W>
where W: UnwindSafe,

§

impl<W> UnwindSafe for StdIoWrite<W>
where W: UnwindSafe,

§

impl<W> UnwindSafe for rustmax::std::io::BufWriter<W>
where W: UnwindSafe + ?Sized,

§

impl<W> UnwindSafe for rustmax::std::io::LineWriter<W>
where W: UnwindSafe + ?Sized,

§

impl<W> UnwindSafe for Ansi<W>
where W: UnwindSafe,

§

impl<W> UnwindSafe for NoColor<W>
where W: UnwindSafe,

§

impl<W> UnwindSafe for rustmax::tokio::io::BufWriter<W>
where W: UnwindSafe,

§

impl<W, F> UnwindSafe for rustmax::serde_json::Serializer<W, F>
where W: UnwindSafe, F: UnwindSafe,

§

impl<W, Item> UnwindSafe for IntoSink<W, Item>
where W: UnwindSafe, Item: UnwindSafe,

§

impl<X> UnwindSafe for Uniform<X>

§

impl<X> UnwindSafe for UniformFloat<X>
where X: UnwindSafe,

§

impl<X> UnwindSafe for UniformInt<X>
where X: UnwindSafe,

§

impl<X> UnwindSafe for WeightedIndex<X>

§

impl<Y, R> UnwindSafe for CoroutineState<Y, R>
where Y: UnwindSafe, R: UnwindSafe,

§

impl<const N: usize> UnwindSafe for LaneCount<N>

impl<'a> UnwindSafe for Location<'a>

impl<'ctx, R> !UnwindSafe for FrameIter<'ctx, R>

impl<'ctx, R> !UnwindSafe for LocationRangeIter<'ctx, R>

impl<'ctx, R> UnwindSafe for Frame<'ctx, R>
where <R as Reader>::Offset: UnwindSafe, R: UnwindSafe,

impl<R> UnwindSafe for Context<R>

impl<R> UnwindSafe for FunctionName<R>
where R: UnwindSafe,

impl UnwindSafe for DFA

impl UnwindSafe for NFA

impl UnwindSafe for NFA

impl UnwindSafe for Match

impl UnwindSafe for Span

impl<'a, 'h> UnwindSafe for FindIter<'a, 'h>

impl<'a, 'h> UnwindSafe for FindOverlappingIter<'a, 'h>

impl<'a, 'h, A> UnwindSafe for FindIter<'a, 'h, A>
where A: RefUnwindSafe,

impl<'a, 'h, A> UnwindSafe for FindOverlappingIter<'a, 'h, A>
where A: RefUnwindSafe,

impl<'a, A, R> UnwindSafe for StreamFindIter<'a, A, R>

impl<'a, R> UnwindSafe for StreamFindIter<'a, R>
where R: UnwindSafe,

impl<'h> UnwindSafe for Input<'h>

impl<'s, 'h> UnwindSafe for FindIter<'s, 'h>

impl<'s> !UnwindSafe for StripBytesIter<'s>

impl<'s> !UnwindSafe for StripStrIter<'s>

impl<'s> !UnwindSafe for WinconBytesIter<'s>

impl<'s> UnwindSafe for StrippedBytes<'s>

impl<'s> UnwindSafe for StrippedStr<'s>

impl<S> UnwindSafe for AutoStream<S>
where S: UnwindSafe,

impl<S> UnwindSafe for StripStream<S>
where S: UnwindSafe,

impl UnwindSafe for State

impl<'a> UnwindSafe for ParamsIter<'a>

impl<C> UnwindSafe for Parser<C>
where C: UnwindSafe,

impl<'a, T, const CAP: usize> UnwindSafe for Drain<'a, T, CAP>
where T: RefUnwindSafe,

impl<T> UnwindSafe for CapacityError<T>
where T: UnwindSafe,

impl<T, const CAP: usize> UnwindSafe for ArrayVec<T, CAP>
where T: UnwindSafe,

impl<T, const CAP: usize> UnwindSafe for IntoIter<T, CAP>
where T: UnwindSafe,

impl<const CAP: usize> UnwindSafe for ArrayString<CAP>

impl<'a, B> UnwindSafe for Difference<'a, B>

impl<'a, B> UnwindSafe for Intersection<'a, B>

impl<'a, B> UnwindSafe for Iter<'a, B>

impl<'a, B> UnwindSafe for SymmetricDifference<'a, B>

impl<'a, B> UnwindSafe for Union<'a, B>

impl<B> UnwindSafe for BitSet<B>
where B: UnwindSafe,

impl<'a, B = u32> !UnwindSafe for IterMut<'a, B>

impl<'a, B> !UnwindSafe for MutBorrowedBit<'a, B>

impl<'a, B> UnwindSafe for Blocks<'a, B>
where B: RefUnwindSafe,

impl<'a, B> UnwindSafe for Iter<'a, B>
where B: RefUnwindSafe,

impl<B> UnwindSafe for BitVec<B>
where B: UnwindSafe,

impl<B> UnwindSafe for IntoIter<B>
where B: UnwindSafe,

impl UnwindSafe for BStr

impl<'a> UnwindSafe for Bytes<'a>

impl<'a> UnwindSafe for CharIndices<'a>

impl<'a> UnwindSafe for Chars<'a>

impl<'a> UnwindSafe for DrainBytes<'a>

impl<'a> UnwindSafe for Fields<'a>

impl<'a> UnwindSafe for Find<'a>

impl<'a> UnwindSafe for FindReverse<'a>

impl<'a> UnwindSafe for Finder<'a>

impl<'a> UnwindSafe for FinderReverse<'a>

impl<'a> UnwindSafe for Lines<'a>

impl<'a> UnwindSafe for Split<'a>

impl<'a> UnwindSafe for SplitN<'a>

impl<'a> UnwindSafe for SplitNReverse<'a>

impl<'a> UnwindSafe for SplitReverse<'a>

impl<'a, F> UnwindSafe for FieldsWith<'a, F>
where F: UnwindSafe,

impl<B> UnwindSafe for ByteLines<B>
where B: UnwindSafe,

impl UnwindSafe for Tz

impl UnwindSafe for Clang

impl<'s> UnwindSafe for ParsedArg<'s>

impl<'s> UnwindSafe for ShortFlags<'s>

impl !UnwindSafe for Error

impl UnwindSafe for Chars

impl<FileId> UnwindSafe for Diagnostic<FileId>
where FileId: UnwindSafe,

impl<FileId> UnwindSafe for Label<FileId>
where FileId: UnwindSafe,

impl<Name, Source> UnwindSafe for SimpleFile<Name, Source>
where Name: UnwindSafe, Source: UnwindSafe,

impl<Name, Source> UnwindSafe for SimpleFiles<Name, Source>
where Name: UnwindSafe, Source: UnwindSafe,

impl UnwindSafe for Case

impl<'a, T> UnwindSafe for StateConverter<'a, T>
where T: RefUnwindSafe,

impl<'a> UnwindSafe for Cfg<'a>

impl<'a> UnwindSafe for AsciiCharsIter<'a>

impl<T> UnwindSafe for BigEndian<T>
where T: UnwindSafe,

impl<T> UnwindSafe for LittleEndian<T>
where T: UnwindSafe,

impl<T> UnwindSafe for FilteredLog<T>
where T: UnwindSafe,

impl UnwindSafe for Rng

impl<'lock, T> !UnwindSafe for RwLockWriteGuard<'lock, T>

impl<'lock, T> UnwindSafe for RwLockReadGuard<'lock, T>
where T: RefUnwindSafe,

impl<T> UnwindSafe for RwLock<T>
where T: UnwindSafe,

impl UnwindSafe for Error

impl UnwindSafe for Error

impl UnwindSafe for Value

impl UnwindSafe for DwAt

impl UnwindSafe for DwAte

impl UnwindSafe for DwCc

impl UnwindSafe for DwCfa

impl UnwindSafe for DwDs

impl UnwindSafe for DwDsc

impl UnwindSafe for DwEnd

impl UnwindSafe for DwId

impl UnwindSafe for DwIdx

impl UnwindSafe for DwInl

impl UnwindSafe for DwLle

impl UnwindSafe for DwLne

impl UnwindSafe for DwLns

impl UnwindSafe for DwOp

impl UnwindSafe for DwOrd

impl UnwindSafe for DwRle

impl UnwindSafe for DwTag

impl UnwindSafe for DwUt

impl UnwindSafe for DwVis

impl UnwindSafe for Range

impl UnwindSafe for Arm

impl UnwindSafe for DwoId

impl UnwindSafe for MIPS

impl UnwindSafe for RiscV

impl UnwindSafe for X86

impl<'a, 'bases, R> UnwindSafe for EhHdrTableIter<'a, 'bases, R>

impl<'a, 'ctx, R, S = StoreOnHeap> !UnwindSafe for UnwindTable<'a, 'ctx, R, S>

impl<'a, R> UnwindSafe for EhHdrTable<'a, R>
where R: RefUnwindSafe,

impl<'a, R> UnwindSafe for UnitRef<'a, R>

impl<'abbrev, 'entry, 'unit, R> !UnwindSafe for AttrsIter<'abbrev, 'entry, 'unit, R>

impl<'abbrev, 'unit, 'tree, R> !UnwindSafe for EntriesTreeIter<'abbrev, 'unit, 'tree, R>

impl<'abbrev, 'unit, 'tree, R> !UnwindSafe for EntriesTreeNode<'abbrev, 'unit, 'tree, R>

impl<'abbrev, 'unit, R> UnwindSafe for EntriesCursor<'abbrev, 'unit, R>

impl<'abbrev, 'unit, R> UnwindSafe for EntriesRaw<'abbrev, 'unit, R>

impl<'abbrev, 'unit, R> UnwindSafe for EntriesTree<'abbrev, 'unit, R>

impl<'abbrev, 'unit, R, Offset> UnwindSafe for DebuggingInformationEntry<'abbrev, 'unit, R, Offset>

impl<'bases, Section, R> UnwindSafe for CieOrFde<'bases, Section, R>
where <R as Reader>::Offset: UnwindSafe, R: UnwindSafe, <Section as UnwindSection<R>>::Offset: UnwindSafe, Section: UnwindSafe,

impl<'bases, Section, R> UnwindSafe for CfiEntriesIter<'bases, Section, R>
where Section: UnwindSafe, R: UnwindSafe,

impl<'bases, Section, R> UnwindSafe for PartialFrameDescriptionEntry<'bases, Section, R>
where <R as Reader>::Offset: UnwindSafe, <Section as UnwindSection<R>>::Offset: UnwindSafe, R: UnwindSafe, Section: UnwindSafe,

impl<'index, R> UnwindSafe for UnitIndexSectionIterator<'index, R>
where R: UnwindSafe,

impl<'input, Endian> UnwindSafe for EndianSlice<'input, Endian>
where Endian: UnwindSafe,

impl<'iter, T> UnwindSafe for RegisterRuleIter<'iter, T>
where T: RefUnwindSafe,

impl<Offset> UnwindSafe for UnitType<Offset>
where Offset: UnwindSafe,

impl<R> UnwindSafe for EvaluationResult<R>
where <R as Reader>::Offset: UnwindSafe, R: UnwindSafe,

impl<R> UnwindSafe for RawLocListEntry<R>
where R: UnwindSafe, <R as Reader>::Offset: UnwindSafe,

impl<R> UnwindSafe for ArangeEntryIter<R>
where R: UnwindSafe,

impl<R> UnwindSafe for ArangeHeaderIter<R>
where R: UnwindSafe, <R as Reader>::Offset: UnwindSafe,

impl<R> UnwindSafe for Attribute<R>
where R: UnwindSafe, <R as Reader>::Offset: UnwindSafe,

impl<R> UnwindSafe for DebugAbbrev<R>
where R: UnwindSafe,

impl<R> UnwindSafe for DebugAddr<R>
where R: UnwindSafe,

impl<R> UnwindSafe for DebugAranges<R>
where R: UnwindSafe,

impl<R> UnwindSafe for DebugCuIndex<R>
where R: UnwindSafe,

impl<R> UnwindSafe for DebugFrame<R>
where R: UnwindSafe,

impl<R> UnwindSafe for DebugInfo<R>
where R: UnwindSafe,

impl<R> UnwindSafe for DebugLine<R>
where R: UnwindSafe,

impl<R> UnwindSafe for DebugLineStr<R>
where R: UnwindSafe,

impl<R> UnwindSafe for DebugLoc<R>
where R: UnwindSafe,

impl<R> UnwindSafe for DebugLocLists<R>
where R: UnwindSafe,

impl<R> UnwindSafe for DebugPubNames<R>
where R: UnwindSafe, <R as Reader>::Offset: UnwindSafe,

impl<R> UnwindSafe for DebugPubTypes<R>
where R: UnwindSafe, <R as Reader>::Offset: UnwindSafe,

impl<R> UnwindSafe for DebugRanges<R>
where R: UnwindSafe,

impl<R> UnwindSafe for DebugRngLists<R>
where R: UnwindSafe,

impl<R> UnwindSafe for DebugStr<R>
where R: UnwindSafe,

impl<R> UnwindSafe for DebugStrOffsets<R>
where R: UnwindSafe,

impl<R> UnwindSafe for DebugTuIndex<R>
where R: UnwindSafe,

impl<R> UnwindSafe for DebugTypes<R>
where R: UnwindSafe,

impl<R> UnwindSafe for Dwarf<R>

impl<R> UnwindSafe for DwarfPackage<R>
where R: UnwindSafe,

impl<R> UnwindSafe for EhFrame<R>
where R: UnwindSafe,

impl<R> UnwindSafe for EhFrameHdr<R>
where R: UnwindSafe,

impl<R> UnwindSafe for Expression<R>
where R: UnwindSafe,

impl<R> UnwindSafe for LineInstructions<R>
where R: UnwindSafe,

impl<R> UnwindSafe for LineSequence<R>
where R: UnwindSafe,

impl<R> UnwindSafe for LocListIter<R>
where R: UnwindSafe, <R as Reader>::Offset: UnwindSafe,

impl<R> UnwindSafe for LocationListEntry<R>
where R: UnwindSafe,

impl<R> UnwindSafe for LocationLists<R>
where R: UnwindSafe,

impl<R> UnwindSafe for OperationIter<R>
where R: UnwindSafe,

impl<R> UnwindSafe for ParsedEhFrameHdr<R>
where R: UnwindSafe,

impl<R> UnwindSafe for PubNamesEntry<R>
where R: UnwindSafe, <R as Reader>::Offset: UnwindSafe,

impl<R> UnwindSafe for PubTypesEntry<R>
where R: UnwindSafe, <R as Reader>::Offset: UnwindSafe,

impl<R> UnwindSafe for RangeIter<R>
where R: UnwindSafe, <R as Reader>::Offset: UnwindSafe,

impl<R> UnwindSafe for RangeLists<R>
where R: UnwindSafe,

impl<R> UnwindSafe for RawLocListIter<R>
where R: UnwindSafe,

impl<R> UnwindSafe for RawRngListIter<R>
where R: UnwindSafe,

impl<R> UnwindSafe for RngListIter<R>
where R: UnwindSafe, <R as Reader>::Offset: UnwindSafe,

impl<R> UnwindSafe for UnitIndex<R>
where R: UnwindSafe,

impl<R, Offset> UnwindSafe for AttributeValue<R, Offset>
where R: UnwindSafe, Offset: UnwindSafe,

impl<R, Offset> UnwindSafe for LineInstruction<R, Offset>
where R: UnwindSafe, Offset: UnwindSafe,

impl<R, Offset> UnwindSafe for Location<R, Offset>
where R: UnwindSafe, Offset: UnwindSafe,

impl<R, Offset> UnwindSafe for Operation<R, Offset>
where R: UnwindSafe, Offset: UnwindSafe,

impl<R, Offset> UnwindSafe for ArangeHeader<R, Offset>
where Offset: UnwindSafe, R: UnwindSafe,

impl<R, Offset> UnwindSafe for CommonInformationEntry<R, Offset>
where Offset: UnwindSafe, R: UnwindSafe,

impl<R, Offset> UnwindSafe for CompleteLineProgram<R, Offset>
where Offset: UnwindSafe, R: UnwindSafe,

impl<R, Offset> UnwindSafe for FileEntry<R, Offset>
where R: UnwindSafe, Offset: UnwindSafe,

impl<R, Offset> UnwindSafe for FrameDescriptionEntry<R, Offset>
where Offset: UnwindSafe, R: UnwindSafe,

impl<R, Offset> UnwindSafe for IncompleteLineProgram<R, Offset>
where Offset: UnwindSafe, R: UnwindSafe,

impl<R, Offset> UnwindSafe for LineProgramHeader<R, Offset>
where Offset: UnwindSafe, R: UnwindSafe,

impl<R, Offset> UnwindSafe for Piece<R, Offset>
where R: UnwindSafe, Offset: UnwindSafe,

impl<R, Offset> UnwindSafe for Unit<R, Offset>
where Offset: UnwindSafe, R: UnwindSafe,

impl<R, Offset> UnwindSafe for UnitHeader<R, Offset>
where Offset: UnwindSafe, R: UnwindSafe,

impl<R, Program, Offset> UnwindSafe for LineRows<R, Program, Offset>
where Program: UnwindSafe, R: UnwindSafe,

impl<R, S> UnwindSafe for Evaluation<R, S>
where R: UnwindSafe, <<S as EvaluationStorage<R>>::Stack as Sealed>::Storage: UnwindSafe, <<S as EvaluationStorage<R>>::ExpressionStack as Sealed>::Storage: UnwindSafe, <<S as EvaluationStorage<R>>::Result as Sealed>::Storage: UnwindSafe,

impl<R, T> UnwindSafe for RelocateReader<R, T>
where R: UnwindSafe, T: UnwindSafe,

impl<T> UnwindSafe for UnitSectionOffset<T>
where T: UnwindSafe,

impl<T> UnwindSafe for CfaRule<T>
where T: UnwindSafe,

impl<T> UnwindSafe for DieReference<T>
where T: UnwindSafe,

impl<T> UnwindSafe for RawRngListEntry<T>
where T: UnwindSafe,

impl<T> UnwindSafe for RegisterRule<T>
where T: UnwindSafe,

impl<T> UnwindSafe for DwarfSections<T>
where T: UnwindSafe,

impl<T> UnwindSafe for UnitOffset<T>
where T: UnwindSafe,

impl<T> UnwindSafe for UnwindExpression<T>
where T: UnwindSafe,

impl<T> UnwindSafe for DebugAbbrevOffset<T>
where T: UnwindSafe,

impl<T> UnwindSafe for DebugAddrBase<T>
where T: UnwindSafe,

impl<T> UnwindSafe for DebugAddrIndex<T>
where T: UnwindSafe,

impl<T> UnwindSafe for DebugArangesOffset<T>
where T: UnwindSafe,

impl<T> UnwindSafe for DebugFrameOffset<T>
where T: UnwindSafe,

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

impl<T> UnwindSafe for DebugLineOffset<T>
where T: UnwindSafe,

impl<T> UnwindSafe for DebugLineStrOffset<T>
where T: UnwindSafe,

impl<T> UnwindSafe for DebugLocListsBase<T>
where T: UnwindSafe,

impl<T> UnwindSafe for DebugLocListsIndex<T>
where T: UnwindSafe,

impl<T> UnwindSafe for DebugMacinfoOffset<T>
where T: UnwindSafe,

impl<T> UnwindSafe for DebugMacroOffset<T>
where T: UnwindSafe,

impl<T> UnwindSafe for DebugRngListsBase<T>
where T: UnwindSafe,

impl<T> UnwindSafe for DebugRngListsIndex<T>
where T: UnwindSafe,

impl<T> UnwindSafe for DebugStrOffset<T>
where T: UnwindSafe,

impl<T> UnwindSafe for DebugStrOffsetsBase<T>
where T: UnwindSafe,

impl<T> UnwindSafe for DebugTypesOffset<T>
where T: UnwindSafe,

impl<T> UnwindSafe for EhFrameOffset<T>
where T: UnwindSafe,

impl<T> UnwindSafe for LocationListsOffset<T>
where T: UnwindSafe,

impl<T> UnwindSafe for RangeListsOffset<T>
where T: UnwindSafe,

impl<T> UnwindSafe for RawRangeListsOffset<T>
where T: UnwindSafe,

impl<T, S> UnwindSafe for UnwindContext<T, S>
where <<S as UnwindContextStorage<T>>::Stack as Sealed>::Storage: UnwindSafe, T: UnwindSafe,

impl<T, S> UnwindSafe for UnwindTableRow<T, S>
where T: UnwindSafe, <<S as UnwindContextStorage<T>>::Rules as Sealed>::Storage: UnwindSafe,

impl !UnwindSafe for Paths

impl UnwindSafe for Error

impl UnwindSafe for Glob

impl<'a> UnwindSafe for Candidate<'a>

impl<'a> UnwindSafe for GlobBuilder<'a>

impl !UnwindSafe for Error

impl UnwindSafe for Ping

impl UnwindSafe for Pong

impl<B> UnwindSafe for SendRequest<B>

impl<B> UnwindSafe for SendResponse<B>

impl<B> UnwindSafe for SendStream<B>

impl<T, B = Bytes> !UnwindSafe for Connection<T, B>

impl<T, B = Bytes> !UnwindSafe for Handshake<T, B>

impl<T, B> !UnwindSafe for Connection<T, B>

impl<'a, 'b, K, Q, V, S, A = Global> !UnwindSafe for EntryRef<'a, 'b, K, Q, V, S, A>

impl<'a, 'b, K, Q, V, S, A = Global> !UnwindSafe for VacantEntryRef<'a, 'b, K, Q, V, S, A>

impl<'a, K> UnwindSafe for Iter<'a, K>
where K: RefUnwindSafe,

impl<'a, K, A> UnwindSafe for Drain<'a, K, A>

impl<'a, K, F, A = Global> !UnwindSafe for ExtractIf<'a, K, F, A>

impl<'a, K, V> !UnwindSafe for IterMut<'a, K, V>

impl<'a, K, V> !UnwindSafe for ValuesMut<'a, K, V>

impl<'a, K, V> UnwindSafe for Iter<'a, K, V>

impl<'a, K, V> UnwindSafe for Keys<'a, K, V>

impl<'a, K, V> UnwindSafe for Values<'a, K, V>

impl<'a, K, V, A> UnwindSafe for Drain<'a, K, V, A>

impl<'a, K, V, F, A = Global> !UnwindSafe for ExtractIf<'a, K, V, F, A>

impl<'a, K, V, S = DefaultHashBuilder, A = Global> !UnwindSafe for OccupiedEntry<'a, K, V, S, A>

impl<'a, K, V, S = DefaultHashBuilder, A = Global> !UnwindSafe for VacantEntry<'a, K, V, S, A>

impl<'a, K, V, S, A = Global> !UnwindSafe for Entry<'a, K, V, S, A>

impl<'a, K, V, S, A = Global> !UnwindSafe for OccupiedError<'a, K, V, S, A>

impl<'a, T> !UnwindSafe for IterHashMut<'a, T>

impl<'a, T> !UnwindSafe for IterMut<'a, T>

impl<'a, T> UnwindSafe for Iter<'a, T>
where T: RefUnwindSafe,

impl<'a, T> UnwindSafe for IterHash<'a, T>

impl<'a, T, A = Global> !UnwindSafe for Entry<'a, T, A>

impl<'a, T, A = Global> !UnwindSafe for AbsentEntry<'a, T, A>

impl<'a, T, A = Global> !UnwindSafe for OccupiedEntry<'a, T, A>

impl<'a, T, A = Global> !UnwindSafe for VacantEntry<'a, T, A>

impl<'a, T, A> UnwindSafe for Drain<'a, T, A>

impl<'a, T, F, A = Global> !UnwindSafe for ExtractIf<'a, T, F, A>

impl<'a, T, S, A = Global> !UnwindSafe for Entry<'a, T, S, A>

impl<'a, T, S, A = Global> !UnwindSafe for OccupiedEntry<'a, T, S, A>

impl<'a, T, S, A = Global> !UnwindSafe for VacantEntry<'a, T, S, A>

impl<'a, T, S, A> UnwindSafe for Difference<'a, T, S, A>

impl<'a, T, S, A> UnwindSafe for Intersection<'a, T, S, A>

impl<'a, T, S, A> UnwindSafe for SymmetricDifference<'a, T, S, A>

impl<'a, T, S, A> UnwindSafe for Union<'a, T, S, A>

impl<K, A> UnwindSafe for IntoIter<K, A>

impl<K, V, A> UnwindSafe for IntoIter<K, V, A>

impl<K, V, A> UnwindSafe for IntoKeys<K, V, A>

impl<K, V, A> UnwindSafe for IntoValues<K, V, A>

impl<K, V, S, A> UnwindSafe for HashMap<K, V, S, A>

impl<T, A> UnwindSafe for IntoIter<T, A>

impl<T, A> UnwindSafe for HashTable<T, A>
where A: UnwindSafe, T: UnwindSafe,

impl<T, S, A> UnwindSafe for HashSet<T, S, A>
where S: UnwindSafe, A: UnwindSafe, T: UnwindSafe,

impl UnwindSafe for Iter

impl UnwindSafe for Iter

impl<'a, T> UnwindSafe for Iter<'a, T>
where T: RefUnwindSafe,

impl<'a, T> UnwindSafe for Iter<'a, T>
where T: RefUnwindSafe,

impl<'a, T> UnwindSafe for Iter<'a, T>
where T: RefUnwindSafe,

impl<'a, T, P> UnwindSafe for HistogramIterator<'a, T, P>

impl<T> UnwindSafe for IterationValue<T>
where T: UnwindSafe,

impl<T> UnwindSafe for Histogram<T>
where T: UnwindSafe,

impl<T> UnwindSafe for AsKebabCase<T>
where T: UnwindSafe,

impl<T> UnwindSafe for AsLowerCamelCase<T>
where T: UnwindSafe,

impl<T> UnwindSafe for AsShoutyKebabCase<T>
where T: UnwindSafe,

impl<T> UnwindSafe for AsShoutySnakeCase<T>
where T: UnwindSafe,

impl<T> UnwindSafe for AsSnakeCase<T>
where T: UnwindSafe,

impl<T> UnwindSafe for AsTitleCase<T>
where T: UnwindSafe,

impl<T> UnwindSafe for AsTrainCase<T>
where T: UnwindSafe,

impl<T> UnwindSafe for AsUpperCamelCase<T>
where T: UnwindSafe,

impl UnwindSafe for OsEnv

impl<'a, T> !UnwindSafe for Frame<'a, T>

impl<B> UnwindSafe for BodyDataStream<B>
where B: UnwindSafe,

impl<B> UnwindSafe for BodyStream<B>
where B: UnwindSafe,

impl<B> UnwindSafe for Collected<B>
where B: UnwindSafe,

impl<B> UnwindSafe for Limited<B>
where B: UnwindSafe,

impl<B, F> UnwindSafe for MapErr<B, F>
where B: UnwindSafe, F: UnwindSafe,

impl<B, F> UnwindSafe for MapFrame<B, F>
where B: UnwindSafe, F: UnwindSafe,

impl<D> UnwindSafe for Empty<D>

impl<D> UnwindSafe for Full<D>
where D: UnwindSafe,

impl<D, E> !UnwindSafe for BoxBody<D, E>

impl<D, E> !UnwindSafe for UnsyncBoxBody<D, E>

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

impl<S> UnwindSafe for StreamBody<S>
where S: UnwindSafe,

impl<T> UnwindSafe for Collect<T>
where T: UnwindSafe + ?Sized, <T as Body>::Data: UnwindSafe,

impl<T, F> UnwindSafe for WithTrailers<T, F>
where T: UnwindSafe, F: UnwindSafe,

impl UnwindSafe for Error

impl<'a> UnwindSafe for Header<'a>

impl<'headers, 'buf> !UnwindSafe for Request<'headers, 'buf>

impl<'headers, 'buf> !UnwindSafe for Response<'headers, 'buf>

impl<T> UnwindSafe for Status<T>
where T: UnwindSafe,

impl UnwindSafe for Error

impl UnwindSafe for Kilo

impl<T, O> UnwindSafe for ISizeFormatter<T, O>
where T: UnwindSafe, O: UnwindSafe,

impl<T, O> UnwindSafe for SizeFormatter<T, O>
where T: UnwindSafe, O: UnwindSafe,

impl UnwindSafe for Error

impl UnwindSafe for Error

impl<T> !UnwindSafe for HttpsConnecting<T>

impl<T> UnwindSafe for MaybeHttpsStream<T>
where T: UnwindSafe,

impl<T> UnwindSafe for HttpsConnector<T>
where T: UnwindSafe,

impl !UnwindSafe for Error

impl UnwindSafe for Name

impl<'a, E> !UnwindSafe for Http1Builder<'a, E>

impl<'a, E> !UnwindSafe for Http2Builder<'a, E>

impl<'a, I, S, E> !UnwindSafe for Connection<'a, I, S, E>

impl<'a, I, S, E> !UnwindSafe for UpgradeableConnection<'a, I, S, E>

impl<C> UnwindSafe for SocksV4<C>
where C: UnwindSafe,

impl<C> UnwindSafe for SocksV5<C>
where C: UnwindSafe,

impl<C> UnwindSafe for Tunnel<C>
where C: UnwindSafe,

impl<C, B> !UnwindSafe for Client<C, B>

impl<E> !UnwindSafe for Builder<E>

impl<I> UnwindSafe for WithHyperIo<I>
where I: UnwindSafe,

impl<I> UnwindSafe for WithTokioIo<I>
where I: UnwindSafe,

impl<R> UnwindSafe for HttpConnector<R>
where R: UnwindSafe,

impl<S> UnwindSafe for TowerToHyperService<S>
where S: UnwindSafe,

impl<S, R> UnwindSafe for TowerToHyperServiceFuture<S, R>
where S: UnwindSafe, <S as Service<R>>::Future: UnwindSafe, R: UnwindSafe,

impl<T> UnwindSafe for TokioIo<T>
where T: UnwindSafe,

impl<T> UnwindSafe for Parts<T>
where T: UnwindSafe,

impl UnwindSafe for Error

impl<'data> UnwindSafe for Char16Trie<'data>

impl<'data> UnwindSafe for CodePointInversionList<'data>

impl<'trie, T> UnwindSafe for CodePointTrie<'trie, T>

impl<T> UnwindSafe for CodePointMapRange<T>
where T: UnwindSafe,

impl UnwindSafe for Other

impl UnwindSafe for Key

impl UnwindSafe for Value

impl UnwindSafe for Key

impl UnwindSafe for Value

impl UnwindSafe for Baked

impl<'data> UnwindSafe for CanonicalCompositions<'data>

impl<'data> UnwindSafe for DecompositionData<'data>

impl<'data> UnwindSafe for DecompositionTables<'data>

impl<'data, I> UnwindSafe for Composition<'data, I>
where I: UnwindSafe,

impl<'data, I> UnwindSafe for Decomposition<'data, I>
where I: UnwindSafe,

impl UnwindSafe for Alnum

impl UnwindSafe for Blank

impl UnwindSafe for Cased

impl UnwindSafe for Dash

impl UnwindSafe for Emoji

impl UnwindSafe for Graph

impl UnwindSafe for Math

impl UnwindSafe for Print

impl UnwindSafe for Baked

impl<'a, T> UnwindSafe for CodePointMapDataBorrowed<'a, T>
where T: RefUnwindSafe, <T as AsULE>::ULE: RefUnwindSafe,

impl<'a, T> UnwindSafe for PropertyParserBorrowed<'a, T>

impl<'data> UnwindSafe for PropertyCodePointSet<'data>

impl<'data> UnwindSafe for PropertyUnicodeSet<'data>

impl<'data> UnwindSafe for PropertyValueNameToEnumMap<'data>

impl<'data, T> UnwindSafe for PropertyCodePointMap<'data, T>

impl<T> UnwindSafe for PropertyParser<T>

impl UnwindSafe for Cart

impl<'a> UnwindSafe for DataRequest<'a>

impl<DataStruct> UnwindSafe for ErasedMarker<DataStruct>
where DataStruct: UnwindSafe,

impl<M, P> UnwindSafe for DataProviderWithMarker<M, P>
where P: UnwindSafe, M: UnwindSafe,

impl<Y> UnwindSafe for NeverMarker<Y>
where Y: UnwindSafe,

impl UnwindSafe for Idna

impl UnwindSafe for Uts46

impl !UnwindSafe for Error

impl !UnwindSafe for Walk

impl UnwindSafe for Glob

impl UnwindSafe for Types

impl<'a> UnwindSafe for Glob<'a>

impl<'a> UnwindSafe for Glob<'a>

impl<T> UnwindSafe for Match<T>
where T: UnwindSafe,

impl<'a, I, K, V, S> !UnwindSafe for Splice<'a, I, K, V, S>

impl<'a, I, T, S> !UnwindSafe for Splice<'a, I, T, S>

impl<'a, K, V> !UnwindSafe for Entry<'a, K, V>

impl<'a, K, V> !UnwindSafe for IndexedEntry<'a, K, V>

impl<'a, K, V> !UnwindSafe for IterMut<'a, K, V>

impl<'a, K, V> !UnwindSafe for IterMut2<'a, K, V>

impl<'a, K, V> !UnwindSafe for OccupiedEntry<'a, K, V>

impl<'a, K, V> !UnwindSafe for VacantEntry<'a, K, V>

impl<'a, K, V> !UnwindSafe for ValuesMut<'a, K, V>

impl<'a, K, V> UnwindSafe for Drain<'a, K, V>

impl<'a, K, V> UnwindSafe for Iter<'a, K, V>

impl<'a, K, V> UnwindSafe for Keys<'a, K, V>

impl<'a, K, V> UnwindSafe for Values<'a, K, V>

impl<'a, K, V, F> !UnwindSafe for ExtractIf<'a, K, V, F>

impl<'a, K, V, S> !UnwindSafe for RawEntryMut<'a, K, V, S>

impl<'a, K, V, S> !UnwindSafe for RawEntryBuilderMut<'a, K, V, S>

impl<'a, K, V, S> !UnwindSafe for RawOccupiedEntryMut<'a, K, V, S>

impl<'a, K, V, S> !UnwindSafe for RawVacantEntryMut<'a, K, V, S>

impl<'a, K, V, S> UnwindSafe for RawEntryBuilder<'a, K, V, S>

impl<'a, T> UnwindSafe for Drain<'a, T>
where T: RefUnwindSafe,

impl<'a, T> UnwindSafe for Iter<'a, T>
where T: RefUnwindSafe,

impl<'a, T, F> !UnwindSafe for ExtractIf<'a, T, F>

impl<'a, T, S> UnwindSafe for Difference<'a, T, S>

impl<'a, T, S> UnwindSafe for Intersection<'a, T, S>

impl<'a, T, S> UnwindSafe for Union<'a, T, S>

impl<'a, T, S1, S2> UnwindSafe for SymmetricDifference<'a, T, S1, S2>

impl<K, V> UnwindSafe for IntoIter<K, V>

impl<K, V> UnwindSafe for IntoKeys<K, V>

impl<K, V> UnwindSafe for Slice<K, V>
where K: UnwindSafe, V: UnwindSafe,

impl<K, V, S> UnwindSafe for IndexMap<K, V, S>
where S: UnwindSafe, K: UnwindSafe, V: UnwindSafe,

impl<T> UnwindSafe for IntoIter<T>

impl<T> UnwindSafe for Slice<T>
where T: UnwindSafe,

impl<T, S> UnwindSafe for IndexSet<T, S>
where S: UnwindSafe, T: UnwindSafe,

impl UnwindSafe for IpNet

impl UnwindSafe for Value

impl UnwindSafe for Error

impl UnwindSafe for Error

impl UnwindSafe for Error

impl<'a> UnwindSafe for Builder<'a>

impl<'a> UnwindSafe for PortBuilder<'a>

impl<'a> UnwindSafe for UserinfoBuilder<'a>

impl<'a> UnwindSafe for VarName<'a>

impl<'a, S> UnwindSafe for FixedBaseResolver<'a, S>

impl<'a, S, C> UnwindSafe for Expanded<'a, S, C>
where C: RefUnwindSafe,

impl<'a, Src> UnwindSafe for MappedToUri<'a, Src>
where Src: RefUnwindSafe + ?Sized,

impl<'a, T> UnwindSafe for Built<'a, T>
where T: ?Sized,

impl<'a, T> UnwindSafe for PasswordMasked<'a, T>
where T: RefUnwindSafe + ?Sized,

impl<'a, T> UnwindSafe for Normalized<'a, T>
where T: ?Sized,

impl<'a, T, D> UnwindSafe for PasswordReplaced<'a, T, D>
where T: RefUnwindSafe + ?Sized, D: UnwindSafe,

impl<S> UnwindSafe for RiAbsoluteStr<S>

impl<S> UnwindSafe for RiFragmentStr<S>

impl<S> UnwindSafe for RiQueryStr<S>

impl<S> UnwindSafe for RiQueryString<S>

impl<S> UnwindSafe for RiReferenceStr<S>

impl<S> UnwindSafe for RiRelativeStr<S>

impl<S> UnwindSafe for RiStr<S>

impl<S> UnwindSafe for RiString<S>

impl<T> UnwindSafe for CreationError<T>
where T: UnwindSafe,

impl<T> UnwindSafe for CreationError<T>
where T: UnwindSafe,

impl<T, S> UnwindSafe for PercentEncoded<T, S>
where T: UnwindSafe,

impl !UnwindSafe for Error

impl<'lib, T> UnwindSafe for Symbol<'lib, T>

impl<T> UnwindSafe for Symbol<T>
where T: UnwindSafe,

impl UnwindSafe for flock

impl UnwindSafe for iovec

impl UnwindSafe for stat

impl UnwindSafe for statx

impl<Storage> UnwindSafe for __BindgenBitfieldUnit<Storage>
where Storage: UnwindSafe,

impl<'a, K, V, S> !UnwindSafe for Entry<'a, K, V, S>

impl<'a, K, V, S> !UnwindSafe for OccupiedEntry<'a, K, V, S>

impl<'a, K, V, S> !UnwindSafe for VacantEntry<'a, K, V, S>

impl<K, V, S> UnwindSafe for LiteMap<K, V, S>
where S: UnwindSafe, K: UnwindSafe + ?Sized, V: UnwindSafe + ?Sized,

impl<'a, R, G, T> !UnwindSafe for MappedReentrantMutexGuard<'a, R, G, T>

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

impl<'a, R, T> !UnwindSafe for MappedMutexGuard<'a, R, T>

impl<'a, R, T> !UnwindSafe for MappedRwLockWriteGuard<'a, R, T>

impl<'a, R, T> !UnwindSafe for MutexGuard<'a, R, T>

impl<'a, R, T> !UnwindSafe for RwLockReadGuard<'a, R, T>

impl<'a, R, T> !UnwindSafe for RwLockUpgradableReadGuard<'a, R, T>

impl<'a, R, T> !UnwindSafe for RwLockWriteGuard<'a, R, T>

impl<'a, R, T> UnwindSafe for MappedRwLockReadGuard<'a, R, T>

impl<R, G> UnwindSafe for RawReentrantMutex<R, G>
where R: UnwindSafe, G: UnwindSafe,

impl<R, G, T> UnwindSafe for ReentrantMutex<R, G, T>
where R: UnwindSafe, G: UnwindSafe, T: UnwindSafe + ?Sized,

impl<R, T> UnwindSafe for Mutex<R, T>
where R: UnwindSafe, T: UnwindSafe + ?Sized,

impl<R, T> UnwindSafe for RwLock<R, T>
where R: UnwindSafe, T: UnwindSafe + ?Sized,

impl<'k, 'v> UnwindSafe for Params<'k, 'v>

impl<'k, 'v, V> UnwindSafe for Match<'k, 'v, V>
where V: UnwindSafe,

impl<'ps, 'k, 'v> UnwindSafe for ParamsIter<'ps, 'k, 'v>

impl<T> UnwindSafe for Router<T>
where T: UnwindSafe,

impl UnwindSafe for One

impl UnwindSafe for Three

impl UnwindSafe for Two

impl UnwindSafe for Pair

impl UnwindSafe for One

impl UnwindSafe for Three

impl UnwindSafe for Two

impl UnwindSafe for One

impl UnwindSafe for Three

impl UnwindSafe for Two

impl<'a, 'h> UnwindSafe for OneIter<'a, 'h>

impl<'a, 'h> UnwindSafe for ThreeIter<'a, 'h>

impl<'a, 'h> UnwindSafe for TwoIter<'a, 'h>

impl<'a, 'h> UnwindSafe for OneIter<'a, 'h>

impl<'a, 'h> UnwindSafe for ThreeIter<'a, 'h>

impl<'a, 'h> UnwindSafe for TwoIter<'a, 'h>

impl<'a, 'h> UnwindSafe for OneIter<'a, 'h>

impl<'a, 'h> UnwindSafe for ThreeIter<'a, 'h>

impl<'a, 'h> UnwindSafe for TwoIter<'a, 'h>

impl<'h> UnwindSafe for Memchr<'h>

impl<'h> UnwindSafe for Memchr2<'h>

impl<'h> UnwindSafe for Memchr3<'h>

impl<'h, 'n> UnwindSafe for FindIter<'h, 'n>

impl<'h, 'n> UnwindSafe for FindRevIter<'h, 'n>

impl<'n> UnwindSafe for Finder<'n>

impl<'n> UnwindSafe for FinderRev<'n>

impl UnwindSafe for Event

impl UnwindSafe for Poll

impl UnwindSafe for Token

impl UnwindSafe for Waker

impl<'a> UnwindSafe for Iter<'a>

impl<'a> UnwindSafe for SourceFd<'a>

impl !UnwindSafe for Error

impl<S> !UnwindSafe for HandshakeError<S>

impl<S> UnwindSafe for TlsStream<S>
where S: UnwindSafe,

impl<A> UnwindSafe for NibbleVec<A>
where A: UnwindSafe,

impl UnwindSafe for Errno

impl UnwindSafe for OFlag

impl UnwindSafe for Mode

impl UnwindSafe for SFlag

impl UnwindSafe for Pid

impl<'a> !UnwindSafe for FcntlArg<'a>

impl<'a> UnwindSafe for SigSetIter<'a>

impl<'a, 'fd> UnwindSafe for Fds<'a, 'fd>

impl<'fd> UnwindSafe for SigevNotify<'fd>

impl<'fd> UnwindSafe for Id<'fd>

impl<'fd> UnwindSafe for PollFd<'fd>

impl<'fd> UnwindSafe for FdSet<'fd>

impl<T> UnwindSafe for Flock<T>
where T: UnwindSafe,

impl<A> UnwindSafe for ExtendedGcd<A>
where A: UnwindSafe,

impl<T> UnwindSafe for IterBinomial<T>
where T: UnwindSafe,

impl UnwindSafe for Ident

impl UnwindSafe for Guid

impl UnwindSafe for Error

impl UnwindSafe for Rel32

impl UnwindSafe for Rel64

impl<'a, R> !UnwindSafe for ReadCacheRange<'a, R>

impl<'data> UnwindSafe for ImportName<'data>

impl<'data> UnwindSafe for ExportTarget<'data>

impl<'data> UnwindSafe for Import<'data>

impl<'data> UnwindSafe for ResourceDirectoryEntryData<'data>

impl<'data> UnwindSafe for ArchiveMember<'data>

impl<'data> UnwindSafe for ArchiveSymbol<'data>

impl<'data> UnwindSafe for ArchiveSymbolIterator<'data>

impl<'data> UnwindSafe for ImportFile<'data>

impl<'data> UnwindSafe for ImportObjectData<'data>

impl<'data> UnwindSafe for SectionTable<'data>

impl<'data> UnwindSafe for AttributeIndexIterator<'data>

impl<'data> UnwindSafe for AttributeReader<'data>

impl<'data> UnwindSafe for AttributesSubsubsection<'data>

impl<'data> UnwindSafe for GnuProperty<'data>

impl<'data> UnwindSafe for Version<'data>

impl<'data> UnwindSafe for DataDirectories<'data>

impl<'data> UnwindSafe for DelayLoadImportTable<'data>

impl<'data> UnwindSafe for Export<'data>

impl<'data> UnwindSafe for ExportTable<'data>

impl<'data> UnwindSafe for ImportDescriptorIterator<'data>

impl<'data> UnwindSafe for ImportTable<'data>

impl<'data> UnwindSafe for ImportThunkList<'data>

impl<'data> UnwindSafe for RelocationBlockIterator<'data>

impl<'data> UnwindSafe for RelocationIterator<'data>

impl<'data> UnwindSafe for ResourceDirectory<'data>

impl<'data> UnwindSafe for ResourceDirectoryTable<'data>

impl<'data> UnwindSafe for RichHeaderInfo<'data>

impl<'data> UnwindSafe for Bytes<'data>

impl<'data> UnwindSafe for CodeView<'data>

impl<'data> UnwindSafe for CompressedData<'data>

impl<'data> UnwindSafe for Export<'data>

impl<'data> UnwindSafe for Import<'data>

impl<'data> UnwindSafe for ObjectMap<'data>

impl<'data> UnwindSafe for ObjectMapEntry<'data>

impl<'data> UnwindSafe for ObjectMapFile<'data>

impl<'data> UnwindSafe for SymbolMapName<'data>

impl<'data, 'cache, E, R> UnwindSafe for DyldCacheImage<'data, 'cache, E, R>

impl<'data, 'cache, E, R> UnwindSafe for DyldCacheImageIterator<'data, 'cache, E, R>

impl<'data, 'file, Elf, R> UnwindSafe for ElfComdat<'data, 'file, Elf, R>

impl<'data, 'file, Elf, R> UnwindSafe for ElfComdatIterator<'data, 'file, Elf, R>

impl<'data, 'file, Elf, R> UnwindSafe for ElfComdatSectionIterator<'data, 'file, Elf, R>

impl<'data, 'file, Elf, R> UnwindSafe for ElfSection<'data, 'file, Elf, R>

impl<'data, 'file, Elf, R> UnwindSafe for ElfSectionIterator<'data, 'file, Elf, R>

impl<'data, 'file, Elf, R> UnwindSafe for ElfSegment<'data, 'file, Elf, R>

impl<'data, 'file, Elf, R> UnwindSafe for ElfSegmentIterator<'data, 'file, Elf, R>

impl<'data, 'file, Elf, R> UnwindSafe for ElfSymbol<'data, 'file, Elf, R>

impl<'data, 'file, Elf, R> UnwindSafe for ElfSymbolIterator<'data, 'file, Elf, R>

impl<'data, 'file, Elf, R> UnwindSafe for ElfSymbolTable<'data, 'file, Elf, R>

impl<'data, 'file, Mach, R> UnwindSafe for MachOComdat<'data, 'file, Mach, R>

impl<'data, 'file, Mach, R> UnwindSafe for MachOComdatIterator<'data, 'file, Mach, R>

impl<'data, 'file, Mach, R> UnwindSafe for MachOComdatSectionIterator<'data, 'file, Mach, R>

impl<'data, 'file, Mach, R> UnwindSafe for MachORelocationIterator<'data, 'file, Mach, R>

impl<'data, 'file, Mach, R> UnwindSafe for MachOSection<'data, 'file, Mach, R>

impl<'data, 'file, Mach, R> UnwindSafe for MachOSectionIterator<'data, 'file, Mach, R>

impl<'data, 'file, Mach, R> UnwindSafe for MachOSegment<'data, 'file, Mach, R>

impl<'data, 'file, Mach, R> UnwindSafe for MachOSegmentIterator<'data, 'file, Mach, R>

impl<'data, 'file, Mach, R> UnwindSafe for MachOSymbol<'data, 'file, Mach, R>

impl<'data, 'file, Mach, R> UnwindSafe for MachOSymbolIterator<'data, 'file, Mach, R>

impl<'data, 'file, Mach, R> UnwindSafe for MachOSymbolTable<'data, 'file, Mach, R>

impl<'data, 'file, Pe, R> UnwindSafe for PeComdat<'data, 'file, Pe, R>

impl<'data, 'file, Pe, R> UnwindSafe for PeComdatIterator<'data, 'file, Pe, R>

impl<'data, 'file, Pe, R> UnwindSafe for PeComdatSectionIterator<'data, 'file, Pe, R>

impl<'data, 'file, Pe, R> UnwindSafe for PeSection<'data, 'file, Pe, R>

impl<'data, 'file, Pe, R> UnwindSafe for PeSectionIterator<'data, 'file, Pe, R>

impl<'data, 'file, Pe, R> UnwindSafe for PeSegment<'data, 'file, Pe, R>

impl<'data, 'file, Pe, R> UnwindSafe for PeSegmentIterator<'data, 'file, Pe, R>

impl<'data, 'file, R> UnwindSafe for PeRelocationIterator<'data, 'file, R>
where R: UnwindSafe,

impl<'data, 'file, R> UnwindSafe for Comdat<'data, 'file, R>
where R: RefUnwindSafe,

impl<'data, 'file, R> UnwindSafe for ComdatIterator<'data, 'file, R>
where R: RefUnwindSafe,

impl<'data, 'file, R> UnwindSafe for ComdatSectionIterator<'data, 'file, R>
where R: RefUnwindSafe,

impl<'data, 'file, R> UnwindSafe for DynamicRelocationIterator<'data, 'file, R>

impl<'data, 'file, R> UnwindSafe for Section<'data, 'file, R>

impl<'data, 'file, R> UnwindSafe for SectionIterator<'data, 'file, R>
where R: RefUnwindSafe,

impl<'data, 'file, R> UnwindSafe for SectionRelocationIterator<'data, 'file, R>

impl<'data, 'file, R> UnwindSafe for Segment<'data, 'file, R>
where R: RefUnwindSafe,

impl<'data, 'file, R> UnwindSafe for SegmentIterator<'data, 'file, R>
where R: RefUnwindSafe,

impl<'data, 'file, R> UnwindSafe for Symbol<'data, 'file, R>

impl<'data, 'file, R> UnwindSafe for SymbolIterator<'data, 'file, R>

impl<'data, 'file, R> UnwindSafe for SymbolTable<'data, 'file, R>

impl<'data, 'file, R, Coff> UnwindSafe for CoffComdat<'data, 'file, R, Coff>

impl<'data, 'file, R, Coff> UnwindSafe for CoffComdatIterator<'data, 'file, R, Coff>

impl<'data, 'file, R, Coff> UnwindSafe for CoffComdatSectionIterator<'data, 'file, R, Coff>

impl<'data, 'file, R, Coff> UnwindSafe for CoffRelocationIterator<'data, 'file, R, Coff>

impl<'data, 'file, R, Coff> UnwindSafe for CoffSection<'data, 'file, R, Coff>

impl<'data, 'file, R, Coff> UnwindSafe for CoffSectionIterator<'data, 'file, R, Coff>

impl<'data, 'file, R, Coff> UnwindSafe for CoffSegment<'data, 'file, R, Coff>

impl<'data, 'file, R, Coff> UnwindSafe for CoffSegmentIterator<'data, 'file, R, Coff>

impl<'data, 'file, R, Coff> UnwindSafe for CoffSymbol<'data, 'file, R, Coff>

impl<'data, 'file, R, Coff> UnwindSafe for CoffSymbolIterator<'data, 'file, R, Coff>

impl<'data, 'file, R, Coff> UnwindSafe for CoffSymbolTable<'data, 'file, R, Coff>

impl<'data, 'file, Xcoff, R> UnwindSafe for XcoffComdat<'data, 'file, Xcoff, R>

impl<'data, 'file, Xcoff, R> UnwindSafe for XcoffComdatIterator<'data, 'file, Xcoff, R>

impl<'data, 'file, Xcoff, R> UnwindSafe for XcoffComdatSectionIterator<'data, 'file, Xcoff, R>

impl<'data, 'file, Xcoff, R> UnwindSafe for XcoffRelocationIterator<'data, 'file, Xcoff, R>

impl<'data, 'file, Xcoff, R> UnwindSafe for XcoffSection<'data, 'file, Xcoff, R>

impl<'data, 'file, Xcoff, R> UnwindSafe for XcoffSectionIterator<'data, 'file, Xcoff, R>

impl<'data, 'file, Xcoff, R> UnwindSafe for XcoffSegment<'data, 'file, Xcoff, R>

impl<'data, 'file, Xcoff, R> UnwindSafe for XcoffSegmentIterator<'data, 'file, Xcoff, R>

impl<'data, 'file, Xcoff, R> UnwindSafe for XcoffSymbol<'data, 'file, Xcoff, R>

impl<'data, 'file, Xcoff, R> UnwindSafe for XcoffSymbolIterator<'data, 'file, Xcoff, R>

impl<'data, 'file, Xcoff, R> UnwindSafe for XcoffSymbolTable<'data, 'file, Xcoff, R>

impl<'data, 'table, R, Coff> UnwindSafe for SymbolIterator<'data, 'table, R, Coff>

impl<'data, 'table, Xcoff, R> UnwindSafe for SymbolIterator<'data, 'table, Xcoff, R>
where Xcoff: RefUnwindSafe, R: RefUnwindSafe,

impl<'data, E> UnwindSafe for DyldSubCacheSlice<'data, E>
where E: RefUnwindSafe,

impl<'data, E> UnwindSafe for LoadCommandVariant<'data, E>
where E: RefUnwindSafe,

impl<'data, E> UnwindSafe for LoadCommandData<'data, E>
where E: UnwindSafe,

impl<'data, E> UnwindSafe for LoadCommandIterator<'data, E>
where E: UnwindSafe,

impl<'data, E, R> UnwindSafe for DyldCache<'data, E, R>

impl<'data, E, R> UnwindSafe for DyldSubCache<'data, E, R>

impl<'data, Elf> UnwindSafe for AttributesSection<'data, Elf>
where <Elf as FileHeader>::Endian: UnwindSafe,

impl<'data, Elf> UnwindSafe for AttributesSubsection<'data, Elf>
where <Elf as FileHeader>::Endian: UnwindSafe,

impl<'data, Elf> UnwindSafe for AttributesSubsectionIterator<'data, Elf>
where <Elf as FileHeader>::Endian: UnwindSafe,

impl<'data, Elf> UnwindSafe for AttributesSubsubsectionIterator<'data, Elf>
where <Elf as FileHeader>::Endian: UnwindSafe,

impl<'data, Elf> UnwindSafe for GnuHashTable<'data, Elf>
where <Elf as FileHeader>::Endian: RefUnwindSafe,

impl<'data, Elf> UnwindSafe for HashTable<'data, Elf>
where <Elf as FileHeader>::Endian: RefUnwindSafe,

impl<'data, Elf> UnwindSafe for Note<'data, Elf>

impl<'data, Elf> UnwindSafe for NoteIterator<'data, Elf>
where <Elf as FileHeader>::Endian: UnwindSafe,

impl<'data, Elf> UnwindSafe for RelrIterator<'data, Elf>

impl<'data, Elf> UnwindSafe for VerdauxIterator<'data, Elf>
where <Elf as FileHeader>::Endian: UnwindSafe,

impl<'data, Elf> UnwindSafe for VerdefIterator<'data, Elf>
where <Elf as FileHeader>::Endian: UnwindSafe,

impl<'data, Elf> UnwindSafe for VernauxIterator<'data, Elf>
where <Elf as FileHeader>::Endian: UnwindSafe,

impl<'data, Elf> UnwindSafe for VerneedIterator<'data, Elf>
where <Elf as FileHeader>::Endian: UnwindSafe,

impl<'data, Elf> UnwindSafe for VersionTable<'data, Elf>
where <Elf as FileHeader>::Endian: RefUnwindSafe,

impl<'data, Elf, R> UnwindSafe for ElfFile<'data, Elf, R>

impl<'data, Elf, R> UnwindSafe for SectionTable<'data, Elf, R>

impl<'data, Elf, R> UnwindSafe for SymbolTable<'data, Elf, R>

impl<'data, Endian> UnwindSafe for GnuPropertyIterator<'data, Endian>
where Endian: UnwindSafe,

impl<'data, Fat> UnwindSafe for MachOFatFile<'data, Fat>
where Fat: RefUnwindSafe,

impl<'data, Mach, R> UnwindSafe for MachOFile<'data, Mach, R>

impl<'data, Mach, R> UnwindSafe for SymbolTable<'data, Mach, R>
where <Mach as MachHeader>::Nlist: RefUnwindSafe, R: UnwindSafe,

impl<'data, Pe, R> UnwindSafe for PeFile<'data, Pe, R>
where R: UnwindSafe, Pe: RefUnwindSafe,

impl<'data, R> UnwindSafe for File<'data, R>
where R: UnwindSafe,

impl<'data, R> UnwindSafe for ArchiveFile<'data, R>
where R: UnwindSafe,

impl<'data, R> UnwindSafe for ArchiveMemberIterator<'data, R>
where R: UnwindSafe,

impl<'data, R> UnwindSafe for StringTable<'data, R>
where R: UnwindSafe,

impl<'data, R, Coff> UnwindSafe for CoffFile<'data, R, Coff>

impl<'data, R, Coff> UnwindSafe for SymbolTable<'data, R, Coff>

impl<'data, Xcoff> UnwindSafe for SectionTable<'data, Xcoff>

impl<'data, Xcoff, R> UnwindSafe for SymbolTable<'data, Xcoff, R>
where Xcoff: UnwindSafe, R: UnwindSafe,

impl<'data, Xcoff, R> UnwindSafe for XcoffFile<'data, Xcoff, R>

impl<E> UnwindSafe for CompressionHeader32<E>
where E: UnwindSafe,

impl<E> UnwindSafe for CompressionHeader64<E>
where E: UnwindSafe,

impl<E> UnwindSafe for Dyn32<E>
where E: UnwindSafe,

impl<E> UnwindSafe for Dyn64<E>
where E: UnwindSafe,

impl<E> UnwindSafe for FileHeader32<E>
where E: UnwindSafe,

impl<E> UnwindSafe for FileHeader64<E>
where E: UnwindSafe,

impl<E> UnwindSafe for GnuHashHeader<E>
where E: UnwindSafe,

impl<E> UnwindSafe for HashHeader<E>
where E: UnwindSafe,

impl<E> UnwindSafe for NoteHeader32<E>
where E: UnwindSafe,

impl<E> UnwindSafe for NoteHeader64<E>
where E: UnwindSafe,

impl<E> UnwindSafe for ProgramHeader32<E>
where E: UnwindSafe,

impl<E> UnwindSafe for ProgramHeader64<E>
where E: UnwindSafe,

impl<E> UnwindSafe for Rel32<E>
where E: UnwindSafe,

impl<E> UnwindSafe for Rel64<E>
where E: UnwindSafe,

impl<E> UnwindSafe for Rela32<E>
where E: UnwindSafe,

impl<E> UnwindSafe for Rela64<E>
where E: UnwindSafe,

impl<E> UnwindSafe for Relr32<E>
where E: UnwindSafe,

impl<E> UnwindSafe for Relr64<E>
where E: UnwindSafe,

impl<E> UnwindSafe for SectionHeader32<E>
where E: UnwindSafe,

impl<E> UnwindSafe for SectionHeader64<E>
where E: UnwindSafe,

impl<E> UnwindSafe for Sym32<E>
where E: UnwindSafe,

impl<E> UnwindSafe for Sym64<E>
where E: UnwindSafe,

impl<E> UnwindSafe for Syminfo32<E>
where E: UnwindSafe,

impl<E> UnwindSafe for Syminfo64<E>
where E: UnwindSafe,

impl<E> UnwindSafe for Verdaux<E>
where E: UnwindSafe,

impl<E> UnwindSafe for Verdef<E>
where E: UnwindSafe,

impl<E> UnwindSafe for Vernaux<E>
where E: UnwindSafe,

impl<E> UnwindSafe for Verneed<E>
where E: UnwindSafe,

impl<E> UnwindSafe for Versym<E>
where E: UnwindSafe,

impl<E> UnwindSafe for I16Bytes<E>
where E: UnwindSafe,

impl<E> UnwindSafe for I32Bytes<E>
where E: UnwindSafe,

impl<E> UnwindSafe for I64Bytes<E>
where E: UnwindSafe,

impl<E> UnwindSafe for U16Bytes<E>
where E: UnwindSafe,

impl<E> UnwindSafe for U32Bytes<E>
where E: UnwindSafe,

impl<E> UnwindSafe for U64Bytes<E>
where E: UnwindSafe,

impl<E> UnwindSafe for BuildToolVersion<E>
where E: UnwindSafe,

impl<E> UnwindSafe for BuildVersionCommand<E>
where E: UnwindSafe,

impl<E> UnwindSafe for DataInCodeEntry<E>
where E: UnwindSafe,

impl<E> UnwindSafe for DyldCacheHeader<E>
where E: UnwindSafe,

impl<E> UnwindSafe for DyldCacheImageInfo<E>
where E: UnwindSafe,

impl<E> UnwindSafe for DyldInfoCommand<E>
where E: UnwindSafe,

impl<E> UnwindSafe for DyldSubCacheEntryV1<E>
where E: UnwindSafe,

impl<E> UnwindSafe for DyldSubCacheEntryV2<E>
where E: UnwindSafe,

impl<E> UnwindSafe for Dylib<E>
where E: UnwindSafe,

impl<E> UnwindSafe for DylibCommand<E>
where E: UnwindSafe,

impl<E> UnwindSafe for DylibModule32<E>
where E: UnwindSafe,

impl<E> UnwindSafe for DylibModule64<E>
where E: UnwindSafe,

impl<E> UnwindSafe for DylibReference<E>
where E: UnwindSafe,

impl<E> UnwindSafe for DylinkerCommand<E>
where E: UnwindSafe,

impl<E> UnwindSafe for DysymtabCommand<E>
where E: UnwindSafe,

impl<E> UnwindSafe for EntryPointCommand<E>
where E: UnwindSafe,

impl<E> UnwindSafe for FilesetEntryCommand<E>
where E: UnwindSafe,

impl<E> UnwindSafe for FvmfileCommand<E>
where E: UnwindSafe,

impl<E> UnwindSafe for Fvmlib<E>
where E: UnwindSafe,

impl<E> UnwindSafe for FvmlibCommand<E>
where E: UnwindSafe,

impl<E> UnwindSafe for IdentCommand<E>
where E: UnwindSafe,

impl<E> UnwindSafe for LcStr<E>
where E: UnwindSafe,

impl<E> UnwindSafe for LinkeditDataCommand<E>
where E: UnwindSafe,

impl<E> UnwindSafe for LinkerOptionCommand<E>
where E: UnwindSafe,

impl<E> UnwindSafe for LoadCommand<E>
where E: UnwindSafe,

impl<E> UnwindSafe for MachHeader32<E>
where E: UnwindSafe,

impl<E> UnwindSafe for MachHeader64<E>
where E: UnwindSafe,

impl<E> UnwindSafe for Nlist32<E>
where E: UnwindSafe,

impl<E> UnwindSafe for Nlist64<E>
where E: UnwindSafe,

impl<E> UnwindSafe for NoteCommand<E>
where E: UnwindSafe,

impl<E> UnwindSafe for PrebindCksumCommand<E>
where E: UnwindSafe,

impl<E> UnwindSafe for Relocation<E>
where E: UnwindSafe,

impl<E> UnwindSafe for RoutinesCommand32<E>
where E: UnwindSafe,

impl<E> UnwindSafe for RoutinesCommand64<E>
where E: UnwindSafe,

impl<E> UnwindSafe for RpathCommand<E>
where E: UnwindSafe,

impl<E> UnwindSafe for Section32<E>
where E: UnwindSafe,

impl<E> UnwindSafe for Section64<E>
where E: UnwindSafe,

impl<E> UnwindSafe for SegmentCommand32<E>
where E: UnwindSafe,

impl<E> UnwindSafe for SegmentCommand64<E>
where E: UnwindSafe,

impl<E> UnwindSafe for SubClientCommand<E>
where E: UnwindSafe,

impl<E> UnwindSafe for SubFrameworkCommand<E>
where E: UnwindSafe,

impl<E> UnwindSafe for SubLibraryCommand<E>
where E: UnwindSafe,

impl<E> UnwindSafe for SubUmbrellaCommand<E>
where E: UnwindSafe,

impl<E> UnwindSafe for SymsegCommand<E>
where E: UnwindSafe,

impl<E> UnwindSafe for SymtabCommand<E>
where E: UnwindSafe,

impl<E> UnwindSafe for ThreadCommand<E>
where E: UnwindSafe,

impl<E> UnwindSafe for TwolevelHint<E>
where E: UnwindSafe,

impl<E> UnwindSafe for UuidCommand<E>
where E: UnwindSafe,

impl<E> UnwindSafe for VersionMinCommand<E>
where E: UnwindSafe,

impl<R> UnwindSafe for ReadCache<R>
where R: UnwindSafe,

impl<Section, Symbol> UnwindSafe for SymbolFlags<Section, Symbol>
where Section: UnwindSafe, Symbol: UnwindSafe,

impl<T> UnwindSafe for SymbolMap<T>
where T: UnwindSafe,

impl !UnwindSafe for Error

impl UnwindSafe for Mode

impl UnwindSafe for Conf

impl UnwindSafe for Open

impl UnwindSafe for Seal

impl UnwindSafe for Error

impl UnwindSafe for Md

impl UnwindSafe for MdRef

impl UnwindSafe for MdCtx

impl UnwindSafe for Nid

impl UnwindSafe for Pkcs7

impl UnwindSafe for Id

impl UnwindSafe for Sha1

impl UnwindSafe for Ssl

impl UnwindSafe for File

impl UnwindSafe for X509

impl<'a> !UnwindSafe for CrlStatus<'a>

impl<'a> !UnwindSafe for OcspStatus<'a>

impl<'a> !UnwindSafe for X509NameEntries<'a>

impl<'a> !UnwindSafe for X509v3Context<'a>

impl<'a> UnwindSafe for Deriver<'a>

impl<'a> UnwindSafe for Decrypter<'a>

impl<'a> UnwindSafe for Encrypter<'a>

impl<'a> UnwindSafe for Signer<'a>

impl<'a> UnwindSafe for Verifier<'a>

impl<'a, T> !UnwindSafe for Iter<'a, T>

impl<'a, T> !UnwindSafe for IterMut<'a, T>

impl<S> !UnwindSafe for HandshakeError<S>

impl<S> UnwindSafe for SslStream<S>
where S: UnwindSafe,

impl<S> UnwindSafe for SslStreamBuilder<S>
where S: UnwindSafe,

impl<T> UnwindSafe for Dh<T>
where T: UnwindSafe,

impl<T> UnwindSafe for DhRef<T>
where T: UnwindSafe,

impl<T> UnwindSafe for Dsa<T>
where T: UnwindSafe,

impl<T> UnwindSafe for DsaRef<T>
where T: UnwindSafe,

impl<T> UnwindSafe for EcKey<T>
where T: UnwindSafe,

impl<T> UnwindSafe for EcKeyRef<T>
where T: UnwindSafe,

impl<T> UnwindSafe for PKey<T>
where T: UnwindSafe,

impl<T> UnwindSafe for PKeyRef<T>
where T: UnwindSafe,

impl<T> UnwindSafe for PkeyCtx<T>
where T: UnwindSafe,

impl<T> UnwindSafe for PkeyCtxRef<T>
where T: UnwindSafe,

impl<T> UnwindSafe for Rsa<T>
where T: UnwindSafe,

impl<T> UnwindSafe for RsaRef<T>
where T: UnwindSafe,

impl<T> UnwindSafe for IntoIter<T>

impl<T> UnwindSafe for Stack<T>

impl<T> UnwindSafe for StackRef<T>
where T: UnwindSafe,

impl<T> UnwindSafe for X509Lookup<T>
where T: UnwindSafe,

impl<T> UnwindSafe for X509LookupMethod<T>
where T: UnwindSafe,

impl<T> UnwindSafe for X509LookupMethodRef<T>
where T: UnwindSafe,

impl<T> UnwindSafe for X509LookupRef<T>
where T: UnwindSafe,

impl<T, U> UnwindSafe for Index<T, U>
where T: UnwindSafe, U: UnwindSafe,

impl UnwindSafe for BIO

impl UnwindSafe for CONF

impl UnwindSafe for DH

impl UnwindSafe for DSA

impl UnwindSafe for RSA

impl UnwindSafe for SSL

impl UnwindSafe for X509

impl UnwindSafe for PKCS7

impl UnwindSafe for Once

impl<'a> UnwindSafe for PercentDecode<'a>

impl<'a> UnwindSafe for PercentEncode<'a>

impl UnwindSafe for Assoc

impl UnwindSafe for Assoc

impl<'i> UnwindSafe for Lines<'i>

impl<'i> UnwindSafe for LinesSpan<'i>

impl<'i> UnwindSafe for Position<'i>

impl<'i> UnwindSafe for Span<'i>

impl<'i, R> UnwindSafe for Token<'i, R>
where R: UnwindSafe,

impl<'i, R> UnwindSafe for FlatPairs<'i, R>
where R: RefUnwindSafe,

impl<'i, R> UnwindSafe for Pair<'i, R>
where R: RefUnwindSafe,

impl<'i, R> UnwindSafe for Pairs<'i, R>
where R: RefUnwindSafe,

impl<'i, R> UnwindSafe for Tokens<'i, R>
where R: RefUnwindSafe,

impl<'i, R> UnwindSafe for ParserState<'i, R>
where R: UnwindSafe,

impl<'pratt, 'a, 'i, R, F, T> !UnwindSafe for PrattParserMap<'pratt, 'a, 'i, R, F, T>

impl<R> UnwindSafe for ErrorVariant<R>
where R: UnwindSafe,

impl<R> UnwindSafe for Error<R>
where R: UnwindSafe,

impl<R> UnwindSafe for Op<R>
where R: UnwindSafe,

impl<R> UnwindSafe for PrattParser<R>
where R: RefUnwindSafe,

impl<R> UnwindSafe for Operator<R>
where R: UnwindSafe,

impl<T> UnwindSafe for Stack<T>
where T: UnwindSafe,

impl UnwindSafe for Expr

impl UnwindSafe for Rule

impl UnwindSafe for Rule

impl<'i> UnwindSafe for ParserExpr<'i>

impl<'i> UnwindSafe for ParserNode<'i>

impl<'i> UnwindSafe for ParserRule<'i>

impl<'a, K, V> UnwindSafe for Entries<'a, K, V>

impl<'a, K, V> UnwindSafe for Keys<'a, K, V>

impl<'a, K, V> UnwindSafe for Values<'a, K, V>

impl<'a, K, V> UnwindSafe for Entries<'a, K, V>

impl<'a, K, V> UnwindSafe for Keys<'a, K, V>

impl<'a, K, V> UnwindSafe for Values<'a, K, V>

impl<'a, T> UnwindSafe for Iter<'a, T>
where T: RefUnwindSafe,

impl<'a, T> UnwindSafe for Iter<'a, T>
where T: RefUnwindSafe,

impl<K, V> UnwindSafe for Map<K, V>

impl<K, V> UnwindSafe for OrderedMap<K, V>

impl<T> UnwindSafe for OrderedSet<T>
where T: RefUnwindSafe,

impl<T> UnwindSafe for Set<T>
where T: RefUnwindSafe,

impl UnwindSafe for NoA1

impl UnwindSafe for NoA2

impl UnwindSafe for NoNI

impl UnwindSafe for NoS3

impl UnwindSafe for NoS4

impl UnwindSafe for YesA1

impl UnwindSafe for YesA2

impl UnwindSafe for YesNI

impl UnwindSafe for YesS3

impl UnwindSafe for YesS4

impl<NI> UnwindSafe for Avx2Machine<NI>
where NI: UnwindSafe,

impl<S3, S4, NI> UnwindSafe for SseMachine<S3, S4, NI>
where S3: UnwindSafe, S4: UnwindSafe, NI: UnwindSafe,

impl !UnwindSafe for Error

impl<X, E> UnwindSafe for Context<X, E>
where X: UnwindSafe, E: UnwindSafe,

impl<'a, K, V> !UnwindSafe for SubTrieMut<'a, K, V>

impl<'a, K, V> UnwindSafe for Children<'a, K, V>

impl<'a, K, V> UnwindSafe for Iter<'a, K, V>

impl<'a, K, V> UnwindSafe for Keys<'a, K, V>

impl<'a, K, V> UnwindSafe for Values<'a, K, V>

impl<'a, K, V> UnwindSafe for SubTrie<'a, K, V>

impl<K, V> UnwindSafe for Trie<K, V>
where K: UnwindSafe, V: UnwindSafe,

impl UnwindSafe for State

impl UnwindSafe for Look

impl UnwindSafe for Cache

impl UnwindSafe for DFA

impl UnwindSafe for Cache

impl UnwindSafe for DFA

impl UnwindSafe for Cache

impl UnwindSafe for Regex

impl UnwindSafe for Cache

impl UnwindSafe for Regex

impl UnwindSafe for Cache

impl UnwindSafe for Cache

impl UnwindSafe for NFA

impl UnwindSafe for Match

impl UnwindSafe for Span

impl UnwindSafe for Unit

impl<'a> UnwindSafe for PatternIter<'a>

impl<'a> UnwindSafe for PatternSetIter<'a>

impl<'a> UnwindSafe for ByteClassElements<'a>

impl<'a> UnwindSafe for ByteClassIter<'a>

impl<'a> UnwindSafe for GroupInfoAllNames<'a>

impl<'a> UnwindSafe for DebugHaystack<'a>

impl<'a, T, F> UnwindSafe for PoolGuard<'a, T, F>

impl<'h> UnwindSafe for Input<'h>

impl<'h> UnwindSafe for Searcher<'h>

impl<'h, F> UnwindSafe for CapturesIter<'h, F>
where F: UnwindSafe,

impl<'h, F> UnwindSafe for HalfMatchesIter<'h, F>
where F: UnwindSafe,

impl<'h, F> UnwindSafe for MatchesIter<'h, F>
where F: UnwindSafe,

impl<'h, F> UnwindSafe for TryCapturesIter<'h, F>
where F: UnwindSafe,

impl<'h, F> UnwindSafe for TryHalfMatchesIter<'h, F>
where F: UnwindSafe,

impl<'h, F> UnwindSafe for TryMatchesIter<'h, F>
where F: UnwindSafe,

impl<'r, 'c, 'h> !UnwindSafe for FindMatches<'r, 'c, 'h>

impl<'r, 'c, 'h> !UnwindSafe for TryCapturesMatches<'r, 'c, 'h>

impl<'r, 'c, 'h> !UnwindSafe for TryFindMatches<'r, 'c, 'h>

impl<'r, 'c, 'h> !UnwindSafe for CapturesMatches<'r, 'c, 'h>

impl<'r, 'c, 'h> !UnwindSafe for FindMatches<'r, 'c, 'h>

impl<'r, 'h> UnwindSafe for CapturesMatches<'r, 'h>

impl<'r, 'h> UnwindSafe for FindMatches<'r, 'h>

impl<'r, 'h> UnwindSafe for Split<'r, 'h>

impl<'r, 'h> UnwindSafe for SplitN<'r, 'h>

impl<B, T> UnwindSafe for AlignAs<B, T>
where B: UnwindSafe + ?Sized, T: UnwindSafe,

impl<T, F> UnwindSafe for Lazy<T, F>

impl<T, F> UnwindSafe for Pool<T, F>

impl UnwindSafe for Ast

impl UnwindSafe for Flag

impl UnwindSafe for Error

impl UnwindSafe for Class

impl UnwindSafe for Dot

impl UnwindSafe for Look

impl UnwindSafe for Error

impl UnwindSafe for Flags

impl UnwindSafe for Group

impl UnwindSafe for Span

impl UnwindSafe for Seq

impl UnwindSafe for Error

impl UnwindSafe for Hir

impl<'a> UnwindSafe for ClassBytesIter<'a>

impl<'a> UnwindSafe for ClassUnicodeIter<'a>

impl<'a> UnwindSafe for Demangle<'a>

impl UnwindSafe for Dir

impl UnwindSafe for Fsid

impl UnwindSafe for Gid

impl UnwindSafe for Mode

impl UnwindSafe for Stat

impl UnwindSafe for Statx

impl UnwindSafe for Uid

impl UnwindSafe for Errno

impl<'a> UnwindSafe for Event<'a>

impl<'a> UnwindSafe for RawDirEntry<'a>

impl<'a, T> !UnwindSafe for SpareCapacity<'a, T>

impl<'a, const OPCODE: u32, Value> !UnwindSafe for Updater<'a, OPCODE, Value>

impl<'buf, Fd> !UnwindSafe for Reader<'buf, Fd>

impl<'buf, Fd> !UnwindSafe for RawDir<'buf, Fd>

impl<const OPCODE: u32> UnwindSafe for IntegerSetter<OPCODE>

impl<const OPCODE: u32> UnwindSafe for NoArg<OPCODE>

impl<const OPCODE: u32, Input> UnwindSafe for Setter<OPCODE, Input>
where Input: UnwindSafe,

impl<const OPCODE: u32, Output> UnwindSafe for Getter<OPCODE, Output>
where Output: UnwindSafe,

impl !UnwindSafe for Error

impl<'a> UnwindSafe for PrivateKeyDer<'a>

impl<'a> UnwindSafe for ServerName<'a>

impl<'a> UnwindSafe for CertificateDer<'a>

impl<'a> UnwindSafe for Der<'a>

impl<'a> UnwindSafe for DnsName<'a>

impl<'a> UnwindSafe for PrivateSec1KeyDer<'a>

impl<'a> UnwindSafe for TrustAnchor<'a>

impl<'a, T> UnwindSafe for SliceIter<'a, T>
where T: UnwindSafe,

impl<R, T> UnwindSafe for ReadIter<R, T>
where R: UnwindSafe, T: UnwindSafe,

impl !UnwindSafe for Error

impl<T, F, S> UnwindSafe for ScopeGuard<T, F, S>
where T: UnwindSafe, F: UnwindSafe,

impl UnwindSafe for Path

impl UnwindSafe for Track

impl<'a> UnwindSafe for Segments<'a>

impl<'a, 'b, D> !UnwindSafe for Deserializer<'a, 'b, D>

impl<'a, 'b, S> !UnwindSafe for Serializer<'a, 'b, S>

impl<E> UnwindSafe for Error<E>
where E: UnwindSafe,

impl UnwindSafe for Error

impl<'de> UnwindSafe for Deserializer<'de>

impl<'input, 'output, T> !UnwindSafe for StructVariantSerializer<'input, 'output, T>

impl<'input, 'output, T> !UnwindSafe for TupleStructSerializer<'input, 'output, T>

impl<'input, 'output, T> !UnwindSafe for TupleVariantSerializer<'input, 'output, T>

impl<'input, 'output, Target> !UnwindSafe for MapSerializer<'input, 'output, Target>

impl<'input, 'output, Target> !UnwindSafe for SeqSerializer<'input, 'output, Target>

impl<'input, 'output, Target> !UnwindSafe for StructSerializer<'input, 'output, Target>

impl<'input, 'output, Target> !UnwindSafe for TupleSerializer<'input, 'output, Target>

impl<'input, 'output, Target> !UnwindSafe for Serializer<'input, 'output, Target>

impl<'a> UnwindSafe for Shlex<'a>

impl<'a> UnwindSafe for Shlex<'a>

impl UnwindSafe for SigId

impl<'a, T> !UnwindSafe for IterMut<'a, T>

impl<'a, T> !UnwindSafe for VacantEntry<'a, T>

impl<'a, T> UnwindSafe for Drain<'a, T>
where T: RefUnwindSafe,

impl<'a, T> UnwindSafe for Iter<'a, T>
where T: RefUnwindSafe,

impl<T> UnwindSafe for IntoIter<T>

impl<T> UnwindSafe for Slab<T>
where T: UnwindSafe,

impl<'a, T> UnwindSafe for Drain<'a, T>

impl<A> UnwindSafe for IntoIter<A>
where <A as Array>::Item: RefUnwindSafe, A: UnwindSafe,

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

impl<F> UnwindSafe for SyncFuture<F>
where F: UnwindSafe,

impl<S> UnwindSafe for SyncStream<S>
where S: UnwindSafe,

impl<T> UnwindSafe for SyncWrapper<T>
where T: UnwindSafe,

impl<'a> UnwindSafe for BindingInfo<'a>

impl<'a> UnwindSafe for Structure<'a>

impl<'a> UnwindSafe for VariantAst<'a>

impl<'a> UnwindSafe for VariantInfo<'a>

impl UnwindSafe for Shake

impl<const N: usize> UnwindSafe for TinyAsciiStr<N>

impl<S> UnwindSafe for AllowStd<S>
where S: UnwindSafe,

impl<S> UnwindSafe for TlsStream<S>
where S: UnwindSafe,

impl UnwindSafe for Token

impl UnwindSafe for Event

impl UnwindSafe for Span

impl<'i> UnwindSafe for Lexer<'i>

impl<'i> UnwindSafe for Raw<'i>

impl<'i> UnwindSafe for Source<'i>

impl<'r> !UnwindSafe for RecursionGuard<'r>

impl<'r, 's> !UnwindSafe for ValidateWhitespace<'r, 's>

impl<'s> UnwindSafe for TomlKey<'s>

impl<'s> UnwindSafe for TomlKeyBuilder<'s>

impl<'s> UnwindSafe for TomlString<'s>

impl<'s> UnwindSafe for TomlStringBuilder<'s>

impl<'a> UnwindSafe for Attempt<'a>

impl<A, B> UnwindSafe for And<A, B>
where A: UnwindSafe, B: UnwindSafe,

impl<A, B> UnwindSafe for Or<A, B>
where A: UnwindSafe, B: UnwindSafe,

impl<C> UnwindSafe for SharedClassifier<C>
where C: UnwindSafe,

impl<C, F> UnwindSafe for MapFailureClass<C, F>
where C: UnwindSafe, F: UnwindSafe,

impl<F> UnwindSafe for CloneBodyFn<F>
where F: UnwindSafe,

impl<F> UnwindSafe for RedirectFn<F>
where F: UnwindSafe,

impl<FailureClass, ClassifyEos> UnwindSafe for ClassifiedResponse<FailureClass, ClassifyEos>
where ClassifyEos: UnwindSafe, FailureClass: UnwindSafe,

impl<P> UnwindSafe for FollowRedirectLayer<P>
where P: UnwindSafe,

impl<S, B, P> !UnwindSafe for ResponseFuture<S, B, P>

impl<S, P> UnwindSafe for FollowRedirect<S, P>
where S: UnwindSafe, P: UnwindSafe,

impl !UnwindSafe for Span

impl<'a> !UnwindSafe for Entered<'a>

impl<T> !UnwindSafe for Instrumented<T>

impl<T> !UnwindSafe for WithDispatch<T>

impl !UnwindSafe for Iter

impl !UnwindSafe for Field

impl UnwindSafe for Empty

impl UnwindSafe for Kind

impl UnwindSafe for Id

impl UnwindSafe for Level

impl<'a> !UnwindSafe for ValueSet<'a>

impl<'a> !UnwindSafe for Attributes<'a>

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

impl<'a> !UnwindSafe for Event<'a>

impl<'a> !UnwindSafe for Metadata<'a>

impl<T> UnwindSafe for DebugValue<T>
where T: UnwindSafe,

impl<T> UnwindSafe for DisplayValue<T>
where T: UnwindSafe,

impl<'a, T> !UnwindSafe for Locked<'a, T>

impl<T> UnwindSafe for TryLock<T>
where T: UnwindSafe,

impl UnwindSafe for Error

impl<'a> UnwindSafe for TrieSetSlice<'a>

impl<T, const N: usize> UnwindSafe for ArrayFromIter<T, N>
where T: UnwindSafe,

impl<'a, V> UnwindSafe for CharDataTableIter<'a, V>
where V: RefUnwindSafe,

impl<V> UnwindSafe for CharDataTable<V>
where V: RefUnwindSafe,

impl<'a> UnwindSafe for GraphemeIndices<'a>

impl<'a> UnwindSafe for Graphemes<'a>

impl<'a> UnwindSafe for WordBoundIndices<'a>

impl<'a> UnwindSafe for WordBounds<'a>

impl<'a> UnwindSafe for Words<'a>

impl<'a> UnwindSafe for Utf8CharIndices<'a>

impl<'a> UnwindSafe for Utf8Chars<'a>

impl !UnwindSafe for Giver

impl !UnwindSafe for Taker

impl UnwindSafe for BStr

impl UnwindSafe for Bytes

impl UnwindSafe for Range

impl<'p, P, I, O, E> !UnwindSafe for ByRef<'p, P, I, O, E>

impl<'t, T> UnwindSafe for TokenSlice<'t, T>
where T: RefUnwindSafe,

impl<C> UnwindSafe for ContextError<C>
where C: UnwindSafe,

impl<E> UnwindSafe for ErrMode<E>
where E: UnwindSafe,

impl<F, G, H, I, O, O2, E> UnwindSafe for FlatMap<F, G, H, I, O, O2, E>

impl<F, G, I, O, E, E2> UnwindSafe for MapErr<F, G, I, O, E, E2>

impl<F, G, I, O, O2, E> UnwindSafe for AndThen<F, G, I, O, O2, E>

impl<F, G, I, O, O2, E> UnwindSafe for Map<F, G, I, O, O2, E>

impl<F, G, I, O, O2, E> UnwindSafe for Verify<F, G, I, O, O2, E>

impl<F, G, I, O, O2, E> UnwindSafe for VerifyMap<F, G, I, O, O2, E>

impl<F, G, I, O, O2, E, E2> UnwindSafe for TryMap<F, G, I, O, O2, E, E2>

impl<F, I, O, E> UnwindSafe for Span<F, I, O, E>

impl<F, I, O, E> UnwindSafe for Take<F, I, O, E>

impl<F, I, O, E> UnwindSafe for Void<F, I, O, E>

impl<F, I, O, E> UnwindSafe for WithSpan<F, I, O, E>

impl<F, I, O, E> UnwindSafe for WithTaken<F, I, O, E>

impl<F, I, O, E> UnwindSafe for ParserIterator<F, I, O, E>

impl<F, I, O, E, C> UnwindSafe for Context<F, I, O, E, C>

impl<F, I, O, E, E2> UnwindSafe for ErrInto<F, I, O, E, E2>

impl<F, I, O, O2, E> UnwindSafe for DefaultValue<F, I, O, O2, E>

impl<F, I, O, O2, E> UnwindSafe for OutputInto<F, I, O, O2, E>

impl<F, I, O, O2, E> UnwindSafe for Value<F, I, O, O2, E>

impl<I> UnwindSafe for InputError<I>
where I: UnwindSafe,

impl<I> UnwindSafe for BitOffsets<I>
where I: UnwindSafe,

impl<I> UnwindSafe for LocatingSlice<I>
where I: UnwindSafe,

impl<I> UnwindSafe for Partial<I>
where I: UnwindSafe,

impl<I, E> UnwindSafe for ParseError<I, E>
where I: UnwindSafe, E: UnwindSafe,

impl<I, S> UnwindSafe for Stateful<I, S>
where I: UnwindSafe, S: UnwindSafe,

impl<P, I, O, C, E> UnwindSafe for Repeat<P, I, O, C, E>

impl<P, I, O, E> UnwindSafe for CompleteErr<P, I, O, E>

impl<P, I, O, E, F, C, FI> UnwindSafe for ContextWith<P, I, O, E, F, C, FI>

impl<P, I, O, O2, E> UnwindSafe for ParseTo<P, I, O, O2, E>

impl<T> UnwindSafe for Caseless<T>
where T: UnwindSafe,

impl<T, S> UnwindSafe for Checkpoint<T, S>
where T: UnwindSafe, S: UnwindSafe,

impl UnwindSafe for Part

impl<T> UnwindSafe for LossyWrap<T>
where T: UnwindSafe,

impl<T> UnwindSafe for WithPart<T>
where T: UnwindSafe + ?Sized,

impl<C0, C1> UnwindSafe for EitherCart<C0, C1>
where C0: UnwindSafe, C1: UnwindSafe,

impl<Y, C> UnwindSafe for Yoke<Y, C>
where C: UnwindSafe, Y: UnwindSafe,

impl<A, S, V> UnwindSafe for ConvertError<A, S, V>
where A: UnwindSafe, S: UnwindSafe, V: UnwindSafe,

impl<B, T> UnwindSafe for Ref<B, T>
where B: UnwindSafe, T: UnwindSafe + ?Sized,

impl<O> UnwindSafe for F32<O>
where O: UnwindSafe,

impl<O> UnwindSafe for F64<O>
where O: UnwindSafe,

impl<O> UnwindSafe for I128<O>
where O: UnwindSafe,

impl<O> UnwindSafe for I16<O>
where O: UnwindSafe,

impl<O> UnwindSafe for I32<O>
where O: UnwindSafe,

impl<O> UnwindSafe for I64<O>
where O: UnwindSafe,

impl<O> UnwindSafe for Isize<O>
where O: UnwindSafe,

impl<O> UnwindSafe for U128<O>
where O: UnwindSafe,

impl<O> UnwindSafe for U16<O>
where O: UnwindSafe,

impl<O> UnwindSafe for U32<O>
where O: UnwindSafe,

impl<O> UnwindSafe for U64<O>
where O: UnwindSafe,

impl<O> UnwindSafe for Usize<O>
where O: UnwindSafe,

impl<Src, Dst> UnwindSafe for AlignmentError<Src, Dst>
where Src: UnwindSafe, Dst: UnwindSafe + ?Sized,

impl<Src, Dst> UnwindSafe for SizeError<Src, Dst>
where Src: UnwindSafe, Dst: UnwindSafe + ?Sized,

impl<Src, Dst> UnwindSafe for ValidityError<Src, Dst>
where Src: UnwindSafe, Dst: UnwindSafe + ?Sized,

impl<T> UnwindSafe for Unalign<T>
where T: UnwindSafe,

impl<Z> UnwindSafe for Zeroizing<Z>
where Z: UnwindSafe,

impl<Store> UnwindSafe for ZeroAsciiIgnoreCaseTrie<Store>
where Store: UnwindSafe + ?Sized,

impl<Store> UnwindSafe for ZeroTrie<Store>
where Store: UnwindSafe,

impl<Store> UnwindSafe for ZeroTrieExtendedCapacity<Store>
where Store: UnwindSafe + ?Sized,

impl<Store> UnwindSafe for ZeroTriePerfectHash<Store>
where Store: UnwindSafe + ?Sized,

impl<Store> UnwindSafe for ZeroTrieSimpleAscii<Store>
where Store: UnwindSafe + ?Sized,

impl<'a, K, V> UnwindSafe for ZeroMapBorrowed<'a, K, V>
where <K as ZeroMapKV<'a>>::Slice: RefUnwindSafe, <V as ZeroMapKV<'a>>::Slice: RefUnwindSafe, K: ?Sized, V: ?Sized,

impl<'a, K, V> UnwindSafe for ZeroMap<'a, K, V>
where <K as ZeroMapKV<'a>>::Container: UnwindSafe, <V as ZeroMapKV<'a>>::Container: UnwindSafe, K: ?Sized, V: ?Sized,

impl<'a, K0, K1, V> UnwindSafe for ZeroMap2dBorrowed<'a, K0, K1, V>
where <K0 as ZeroMapKV<'a>>::Slice: RefUnwindSafe, <K1 as ZeroMapKV<'a>>::Slice: RefUnwindSafe, <V as ZeroMapKV<'a>>::Slice: RefUnwindSafe, K0: ?Sized, K1: ?Sized, V: ?Sized,

impl<'a, K0, K1, V> UnwindSafe for ZeroMap2d<'a, K0, K1, V>
where <K0 as ZeroMapKV<'a>>::Container: UnwindSafe, <K1 as ZeroMapKV<'a>>::Container: UnwindSafe, <V as ZeroMapKV<'a>>::Container: UnwindSafe, K0: ?Sized, K1: ?Sized, V: ?Sized,

impl<'a, T> UnwindSafe for ZeroVec<'a, T>
where <T as AsULE>::ULE: UnwindSafe + RefUnwindSafe,

impl<'a, T> UnwindSafe for ZeroSliceIter<'a, T>
where <T as AsULE>::ULE: RefUnwindSafe,

impl<'a, T, F> UnwindSafe for VarZeroVec<'a, T, F>

impl<'a, T, F> UnwindSafe for VarZeroSliceIter<'a, T, F>
where F: UnwindSafe, T: RefUnwindSafe + ?Sized,

impl<'a, V> UnwindSafe for VarZeroCow<'a, V>

impl<'l, 'a, K0, K1, V> UnwindSafe for ZeroMap2dCursor<'l, 'a, K0, K1, V>
where <K0 as ZeroMapKV<'a>>::Slice: RefUnwindSafe, <K1 as ZeroMapKV<'a>>::Slice: RefUnwindSafe, <V as ZeroMapKV<'a>>::Slice: RefUnwindSafe, K0: ?Sized, K1: ?Sized, V: ?Sized,

impl<A, B> UnwindSafe for Tuple2ULE<A, B>
where A: UnwindSafe, B: UnwindSafe,

impl<A, B> UnwindSafe for VarTuple<A, B>
where A: UnwindSafe, B: UnwindSafe,

impl<A, B, C> UnwindSafe for Tuple3ULE<A, B, C>
where A: UnwindSafe, B: UnwindSafe, C: UnwindSafe,

impl<A, B, C, D> UnwindSafe for Tuple4ULE<A, B, C, D>

impl<A, B, C, D, E> UnwindSafe for Tuple5ULE<A, B, C, D, E>

impl<A, B, C, D, E, F> UnwindSafe for Tuple6ULE<A, B, C, D, E, F>

impl<A, B, C, D, E, F, Format> UnwindSafe for Tuple6VarULE<A, B, C, D, E, F, Format>
where A: UnwindSafe + ?Sized, B: UnwindSafe + ?Sized, C: UnwindSafe + ?Sized, D: UnwindSafe + ?Sized, E: UnwindSafe + ?Sized, F: UnwindSafe + ?Sized, Format: UnwindSafe,

impl<A, B, C, D, E, Format> UnwindSafe for Tuple5VarULE<A, B, C, D, E, Format>
where A: UnwindSafe + ?Sized, B: UnwindSafe + ?Sized, C: UnwindSafe + ?Sized, D: UnwindSafe + ?Sized, E: UnwindSafe + ?Sized, Format: UnwindSafe,

impl<A, B, C, D, Format> UnwindSafe for Tuple4VarULE<A, B, C, D, Format>
where A: UnwindSafe + ?Sized, B: UnwindSafe + ?Sized, C: UnwindSafe + ?Sized, D: UnwindSafe + ?Sized, Format: UnwindSafe,

impl<A, B, C, Format> UnwindSafe for Tuple3VarULE<A, B, C, Format>
where A: UnwindSafe + ?Sized, B: UnwindSafe + ?Sized, C: UnwindSafe + ?Sized, Format: UnwindSafe,

impl<A, B, Format> UnwindSafe for Tuple2VarULE<A, B, Format>
where A: UnwindSafe + ?Sized, B: UnwindSafe + ?Sized, Format: UnwindSafe,

impl<A, V> UnwindSafe for VarTupleULE<A, V>
where <A as AsULE>::ULE: UnwindSafe, V: UnwindSafe + ?Sized,

impl<T> UnwindSafe for ZeroSlice<T>
where <T as AsULE>::ULE: UnwindSafe,

impl<T, F> UnwindSafe for VarZeroSlice<T, F>
where F: UnwindSafe, T: UnwindSafe + ?Sized,

impl<T, F> UnwindSafe for VarZeroVecOwned<T, F>
where T: UnwindSafe + ?Sized, F: UnwindSafe,

impl<U> UnwindSafe for OptionULE<U>
where U: UnwindSafe,

impl<U> UnwindSafe for OptionVarULE<U>
where U: UnwindSafe + ?Sized,

impl<U, const N: usize> UnwindSafe for NichedOption<U, N>
where U: UnwindSafe,

impl<U, const N: usize> UnwindSafe for NichedOptionULE<U, N>
where U: UnwindSafe,

impl<const LEN: usize, Format> UnwindSafe for MultiFieldsULE<LEN, Format>
where Format: UnwindSafe,

impl<const N: usize> UnwindSafe for RawBytesULE<N>