pub trait Debug {
// Required method
fn fmt(&self, f: &mut Formatter<'_>) -> Result<(), Error>;
}
Expand description
?
formatting.
Debug
should format the output in a programmer-facing, debugging context.
Generally speaking, you should just derive
a Debug
implementation.
When used with the alternate format specifier #?
, the output is pretty-printed.
For more information on formatters, see the module-level documentation.
This trait can be used with #[derive]
if all fields implement Debug
. When
derive
d for structs, it will use the name of the struct
, then {
, then a
comma-separated list of each field’s name and Debug
value, then }
. For
enum
s, it will use the name of the variant and, if applicable, (
, then the
Debug
values of the fields, then )
.
§Stability
Derived Debug
formats are not stable, and so may change with future Rust
versions. Additionally, Debug
implementations of types provided by the
standard library (std
, core
, alloc
, etc.) are not stable, and
may also change with future Rust versions.
§Examples
Deriving an implementation:
#[derive(Debug)]
struct Point {
x: i32,
y: i32,
}
let origin = Point { x: 0, y: 0 };
assert_eq!(
format!("The origin is: {origin:?}"),
"The origin is: Point { x: 0, y: 0 }",
);
Manually implementing:
use std::fmt;
struct Point {
x: i32,
y: i32,
}
impl fmt::Debug for Point {
fn fmt(&self, f: &mut fmt::Formatter<'_>) -> fmt::Result {
f.debug_struct("Point")
.field("x", &self.x)
.field("y", &self.y)
.finish()
}
}
let origin = Point { x: 0, y: 0 };
assert_eq!(
format!("The origin is: {origin:?}"),
"The origin is: Point { x: 0, y: 0 }",
);
There are a number of helper methods on the Formatter
struct to help you with manual
implementations, such as debug_struct
.
Types that do not wish to use the standard suite of debug representations
provided by the Formatter
trait (debug_struct
, debug_tuple
,
debug_list
, debug_set
, debug_map
) can do something totally custom by
manually writing an arbitrary representation to the Formatter
.
impl fmt::Debug for Point {
fn fmt(&self, f: &mut fmt::Formatter<'_>) -> fmt::Result {
write!(f, "Point [{} {}]", self.x, self.y)
}
}
Debug
implementations using either derive
or the debug builder API
on Formatter
support pretty-printing using the alternate flag: {:#?}
.
Pretty-printing with #?
:
#[derive(Debug)]
struct Point {
x: i32,
y: i32,
}
let origin = Point { x: 0, y: 0 };
let expected = "The origin is: Point {
x: 0,
y: 0,
}";
assert_eq!(format!("The origin is: {origin:#?}"), expected);
Required Methods§
1.0.0 · Sourcefn fmt(&self, f: &mut Formatter<'_>) -> Result<(), Error>
fn fmt(&self, f: &mut Formatter<'_>) -> Result<(), Error>
Formats the value using the given formatter.
§Errors
This function should return Err
if, and only if, the provided Formatter
returns Err
.
String formatting is considered an infallible operation; this function only
returns a Result
because writing to the underlying stream might fail and it must
provide a way to propagate the fact that an error has occurred back up the stack.
§Examples
use std::fmt;
struct Position {
longitude: f32,
latitude: f32,
}
impl fmt::Debug for Position {
fn fmt(&self, f: &mut fmt::Formatter<'_>) -> fmt::Result {
f.debug_tuple("")
.field(&self.longitude)
.field(&self.latitude)
.finish()
}
}
let position = Position { longitude: 1.987, latitude: 2.983 };
assert_eq!(format!("{position:?}"), "(1.987, 2.983)");
assert_eq!(format!("{position:#?}"), "(
1.987,
2.983,
)");
Implementors§
impl Debug for llm_tools::secret::Error
impl Debug for AsciiChar
impl Debug for llm_tools::ser::core::cmp::Ordering
impl Debug for Infallible
impl Debug for FromBytesWithNulError
impl Debug for c_void
impl Debug for llm_tools::ser::core::net::IpAddr
impl Debug for Ipv6MulticastScope
impl Debug for llm_tools::ser::core::net::SocketAddr
impl Debug for FpCategory
impl Debug for IntErrorKind
impl Debug for llm_tools::ser::core::slice::GetDisjointMutError
impl Debug for SearchStep
impl Debug for llm_tools::ser::core::sync::atomic::Ordering
impl Debug for llm_tools::ser::core::fmt::Alignment
impl Debug for DebugAsHex
impl Debug for Sign
impl Debug for TryReserveErrorKind
impl Debug for BacktraceStatus
impl Debug for VarError
impl Debug for std::fs::TryLockError
impl Debug for SeekFrom
impl Debug for ErrorKind
impl Debug for Shutdown
impl Debug for AncillaryError
impl Debug for BacktraceStyle
impl Debug for RecvTimeoutError
impl Debug for std::sync::mpsc::TryRecvError
impl Debug for ParseAlphabetError
impl Debug for base64::decode::DecodeError
impl Debug for DecodeSliceError
impl Debug for EncodeSliceError
impl Debug for DecodePaddingMode
impl Debug for byteorder::BigEndian
impl Debug for byteorder::LittleEndian
impl Debug for BitOrder
impl Debug for DecodeKind
impl Debug for TruncSide
impl Debug for dotenv::errors::Error
impl Debug for CoderResult
impl Debug for DecoderResult
impl Debug for EncoderResult
impl Debug for Latin1Bidi
impl Debug for LineType
impl Debug for PollNext
impl Debug for hashbrown::TryReserveError
impl Debug for httparse::Error
impl Debug for TrieResult
impl Debug for InvalidStringList
impl Debug for TrieType
impl Debug for icu_collections::codepointtrie::error::Error
impl Debug for ExtensionType
impl Debug for icu_locale_core::parser::errors::ParseError
impl Debug for PreferencesParseError
impl Debug for Decomposed
impl Debug for BidiPairedBracketType
impl Debug for GeneralCategory
impl Debug for BufferFormat
impl Debug for DataErrorKind
impl Debug for ProcessingError
impl Debug for ProcessingSuccess
impl Debug for indexmap::GetDisjointMutError
impl Debug for IpAddrRange
impl Debug for IpNet
impl Debug for IpSubnets
impl Debug for IriSpec
impl Debug for UriSpec
impl Debug for VisitPurpose
impl Debug for iri_string::template::simple_context::Value
impl Debug for log::Level
impl Debug for log::LevelFilter
impl Debug for PrefilterConfig
impl Debug for native_tls::Protocol
impl Debug for ClientEvent
impl Debug for ServerEvent
impl Debug for AudioFormat
impl Debug for ContentPart
impl Debug for FunctionType
impl Debug for IncompleteReason
impl Debug for ItemContentType
impl Debug for ItemRole
impl Debug for ItemStatus
impl Debug for ItemType
impl Debug for MaxOutputTokens
impl Debug for RealtimeVoice
impl Debug for ResponseStatus
impl Debug for ResponseStatusDetail
impl Debug for ToolChoice
impl Debug for ToolDefinition
impl Debug for TurnDetection
impl Debug for FileSearchRanker
impl Debug for Tools
impl Debug for openai_api_rs::v1::chat_completion::Content
impl Debug for ContentType
impl Debug for FinishReason
impl Debug for openai_api_rs::v1::chat_completion::MessageRole
impl Debug for ToolChoiceType
impl Debug for ToolType
impl Debug for openai_api_rs::v1::error::APIError
impl Debug for openai_api_rs::v1::message::MessageRole
impl Debug for openai_api_rs::v1::thread::MessageRole
impl Debug for JSONSchemaType
impl Debug for ShutdownResult
impl Debug for parking_lot::once::OnceState
impl Debug for FilterOp
impl Debug for ParkResult
impl Debug for RequeueOp
impl Debug for BernoulliError
impl Debug for WeightedError
impl Debug for IndexVec
impl Debug for IndexVecIntoIter
impl Debug for Primitive
impl Debug for rustls_pki_types::pem::Error
impl Debug for SectionKind
impl Debug for rustls_pki_types::server_name::IpAddr
impl Debug for ServerName<'_>
impl Debug for Always
impl Debug for Category
impl Debug for serde_json::value::Value
impl Debug for serde_urlencoded::ser::Error
impl Debug for CollectionAllocErr
impl Debug for InterfaceIndexOrAddress
impl Debug for tinystr::error::ParseError
impl Debug for tokio_socks::error::Error
impl Debug for AnyDelimiterCodecError
impl Debug for LinesCodecError
impl Debug for RuntimeFlavor
impl Debug for TryAcquireError
impl Debug for tokio::sync::broadcast::error::RecvError
impl Debug for tokio::sync::broadcast::error::TryRecvError
impl Debug for tokio::sync::mpsc::error::TryRecvError
impl Debug for tokio::sync::oneshot::error::TryRecvError
impl Debug for MissedTickBehavior
impl Debug for ServerErrorsFailureClass
impl Debug for GrpcCode
impl Debug for GrpcFailureClass
impl Debug for StatusInRangeFailureClass
impl Debug for LatencyUnit
impl Debug for tower_http::follow_redirect::policy::Action
impl Debug for CapacityError
impl Debug for tungstenite::error::Error
impl Debug for ProtocolError
impl Debug for SubProtocolError
impl Debug for TlsError
impl Debug for UrlError
impl Debug for Role
impl Debug for CloseCode
impl Debug for Control
impl Debug for tungstenite::protocol::frame::coding::Data
impl Debug for OpCode
impl Debug for tungstenite::protocol::message::Message
impl Debug for Mode
impl Debug for Origin
impl Debug for url::parser::ParseError
impl Debug for SyntaxViolation
impl Debug for Position
impl Debug for zerocopy::byteorder::BigEndian
impl Debug for zerocopy::byteorder::LittleEndian
impl Debug for ZeroTrieBuildError
impl Debug for UleError
impl Debug for bool
impl Debug for char
impl Debug for f16
impl Debug for f32
impl Debug for f64
impl Debug for f128
impl Debug for i8
impl Debug for i16
impl Debug for i32
impl Debug for i64
impl Debug for i128
impl Debug for isize
impl Debug for !
impl Debug for str
impl Debug for u8
impl Debug for u16
impl Debug for u32
impl Debug for u64
impl Debug for u128
impl Debug for ()
impl Debug for usize
impl Debug for AssistantObject
impl Debug for AssistantObjectWrap
impl Debug for FileDataWrap
impl Debug for RunObjectWrap
impl Debug for Secret
impl Debug for TableConfig
impl Debug for IgnoredAny
impl Debug for llm_tools::ser::serde::de::value::Error
impl Debug for llm_tools::ser::core::alloc::AllocError
impl Debug for Layout
impl Debug for LayoutError
impl Debug for TypeId
impl Debug for CpuidResult
impl Debug for __m128
impl Debug for __m128bh
impl Debug for __m128d
impl Debug for __m128h
impl Debug for __m128i
impl Debug for __m256
impl Debug for __m256bh
impl Debug for __m256d
impl Debug for __m256h
impl Debug for __m256i
impl Debug for __m512
impl Debug for __m512bh
impl Debug for __m512d
impl Debug for __m512h
impl Debug for __m512i
impl Debug for bf16
impl Debug for TryFromSliceError
impl Debug for llm_tools::ser::core::ascii::EscapeDefault
impl Debug for ByteStr
impl Debug for BorrowError
impl Debug for BorrowMutError
impl Debug for CharTryFromError
impl Debug for DecodeUtf16Error
impl Debug for llm_tools::ser::core::char::EscapeDebug
impl Debug for llm_tools::ser::core::char::EscapeDefault
impl Debug for llm_tools::ser::core::char::EscapeUnicode
impl Debug for ParseCharError
impl Debug for ToLowercase
impl Debug for ToUppercase
impl Debug for TryFromCharError
impl Debug for CStr
impl Debug for FromBytesUntilNulError
impl Debug for SipHasher
impl Debug for BorrowedBuf<'_>
impl Debug for PhantomContravariantLifetime<'_>
impl Debug for PhantomCovariantLifetime<'_>
impl Debug for PhantomInvariantLifetime<'_>
impl Debug for PhantomPinned
impl Debug for Assume
impl Debug for llm_tools::ser::core::net::AddrParseError
impl Debug for llm_tools::ser::core::net::Ipv4Addr
impl Debug for llm_tools::ser::core::net::Ipv6Addr
impl Debug for SocketAddrV4
impl Debug for SocketAddrV6
impl Debug for ParseFloatError
impl Debug for ParseIntError
impl Debug for TryFromIntError
impl Debug for RangeFull
impl Debug for PanicMessage<'_>
impl Debug for llm_tools::ser::core::ptr::Alignment
impl Debug for Chars<'_>
impl Debug for EncodeUtf16<'_>
impl Debug for ParseBoolError
impl Debug for Utf8Chunks<'_>
impl Debug for Utf8Error
impl Debug for AtomicBool
impl Debug for AtomicI8
impl Debug for AtomicI16
impl Debug for AtomicI32
impl Debug for AtomicI64
impl Debug for AtomicIsize
impl Debug for AtomicU8
impl Debug for AtomicU16
impl Debug for AtomicU32
impl Debug for AtomicU64
impl Debug for AtomicUsize
impl Debug for llm_tools::ser::core::task::Context<'_>
impl Debug for LocalWaker
impl Debug for RawWaker
impl Debug for RawWakerVTable
impl Debug for llm_tools::ser::core::task::Waker
impl Debug for Duration
impl Debug for TryFromFloatSecsError
impl Debug for Global
impl Debug for ByteString
impl Debug for UnorderedKeyError
impl Debug for alloc::collections::TryReserveError
impl Debug for CString
impl Debug for FromVecWithNulError
impl Debug for IntoStringError
impl Debug for NulError
impl Debug for alloc::string::Drain<'_>
impl Debug for FromUtf8Error
impl Debug for FromUtf16Error
impl Debug for IntoChars
impl Debug for String
impl Debug for System
impl Debug for Backtrace
impl Debug for BacktraceFrame
impl Debug for Args
impl Debug for ArgsOs
impl Debug for JoinPathsError
impl Debug for SplitPaths<'_>
impl Debug for Vars
impl Debug for VarsOs
impl Debug for std::ffi::os_str::Display<'_>
impl Debug for OsStr
impl Debug for OsString
impl Debug for std::fs::DirBuilder
impl Debug for std::fs::DirEntry
impl Debug for std::fs::File
impl Debug for FileTimes
impl Debug for FileType
impl Debug for std::fs::Metadata
impl Debug for std::fs::OpenOptions
impl Debug for Permissions
impl Debug for std::fs::ReadDir
impl Debug for DefaultHasher
impl Debug for RandomState
impl Debug for WriterPanicked
impl Debug for std::io::error::Error
impl Debug for PipeReader
impl Debug for PipeWriter
impl Debug for std::io::stdio::Stderr
impl Debug for StderrLock<'_>
impl Debug for std::io::stdio::Stdin
impl Debug for StdinLock<'_>
impl Debug for std::io::stdio::Stdout
impl Debug for StdoutLock<'_>
impl Debug for std::io::util::Empty
impl Debug for std::io::util::Repeat
impl Debug for std::io::util::Sink
impl Debug for IntoIncoming
impl Debug for std::net::tcp::TcpListener
impl Debug for std::net::tcp::TcpStream
impl Debug for std::net::udp::UdpSocket
impl Debug for BorrowedFd<'_>
impl Debug for OwnedFd
impl Debug for PidFd
impl Debug for std::os::unix::net::addr::SocketAddr
impl Debug for std::os::unix::net::datagram::UnixDatagram
impl Debug for std::os::unix::net::listener::UnixListener
impl Debug for std::os::unix::net::stream::UnixStream
impl Debug for std::os::unix::net::ucred::UCred
impl Debug for Components<'_>
impl Debug for std::path::Display<'_>
impl Debug for std::path::Iter<'_>
impl Debug for NormalizeError
impl Debug for Path
impl Debug for PathBuf
impl Debug for StripPrefixError
impl Debug for std::process::Child
impl Debug for std::process::ChildStderr
impl Debug for std::process::ChildStdin
impl Debug for std::process::ChildStdout
impl Debug for std::process::Command
impl Debug for ExitCode
impl Debug for ExitStatus
impl Debug for ExitStatusError
impl Debug for Output
impl Debug for Stdio
impl Debug for DefaultRandomSource
impl Debug for std::sync::barrier::Barrier
impl Debug for std::sync::barrier::BarrierWaitResult
impl Debug for std::sync::mpsc::RecvError
impl Debug for std::sync::poison::condvar::Condvar
impl Debug for std::sync::poison::condvar::WaitTimeoutResult
impl Debug for std::sync::poison::once::Once
impl Debug for std::sync::poison::once::OnceState
impl Debug for AccessError
impl Debug for Scope<'_, '_>
impl Debug for std::thread::Builder
impl Debug for Thread
impl Debug for ThreadId
impl Debug for std::time::Instant
impl Debug for SystemTime
impl Debug for SystemTimeError
impl Debug for anyhow::Error
impl Debug for atomic_waker::AtomicWaker
impl Debug for Alphabet
impl Debug for GeneralPurpose
impl Debug for GeneralPurposeConfig
impl Debug for DecodeMetadata
impl Debug for bitflags::parser::ParseError
impl Debug for Eager
impl Debug for block_buffer::Error
impl Debug for block_buffer::Lazy
impl Debug for UninitSlice
impl Debug for bytes::bytes::Bytes
impl Debug for BytesMut
impl Debug for TryGetError
impl Debug for FromPathBufError
impl Debug for FromPathError
impl Debug for camino::Iter<'_>
impl Debug for ReadDirUtf8
impl Debug for Utf8DirEntry
impl Debug for Utf8Path
impl Debug for Utf8PathBuf
impl Debug for InvalidLength
impl Debug for data_encoding::DecodeError
impl Debug for DecodePartial
impl Debug for data_encoding::Encoding
impl Debug for Specification
impl Debug for SpecificationError
impl Debug for Translate
impl Debug for Wrap
impl Debug for InvalidBufferSize
impl Debug for InvalidOutputSize
impl Debug for encoding_rs::Encoding
impl Debug for format_tools::format::filter::private::All
impl Debug for format_tools::format::filter::private::None
impl Debug for format_tools::format::output_format::keys::Keys
impl Debug for Records
impl Debug for Table
impl Debug for format_tools::format::print::private::Context<'_>
impl Debug for RowDescriptor
impl Debug for TestObjectWithoutImpl
impl Debug for WithDebug
impl Debug for WithDebugMultiline
impl Debug for WithDisplay
impl Debug for WithRef
impl Debug for WithWell
impl Debug for NoEnd
impl Debug for ReturnPreformed
impl Debug for ReturnStorage
impl Debug for futures_channel::mpsc::SendError
impl Debug for futures_channel::mpsc::TryRecvError
impl Debug for Canceled
impl Debug for futures_core::task::__internal::atomic_waker::AtomicWaker
impl Debug for SpawnError
impl Debug for futures_util::abortable::AbortHandle
impl Debug for AbortRegistration
impl Debug for Aborted
impl Debug for getrandom::error::Error
impl Debug for h2::client::Builder
impl Debug for PushPromise
impl Debug for PushPromises
impl Debug for PushedResponseFuture
impl Debug for h2::client::ResponseFuture
impl Debug for h2::error::Error
impl Debug for h2::ext::Protocol
impl Debug for Reason
impl Debug for h2::server::Builder
impl Debug for FlowControl
impl Debug for Ping
impl Debug for PingPong
impl Debug for Pong
impl Debug for RecvStream
impl Debug for StreamId
impl Debug for LengthLimitError
impl Debug for SizeHint
impl Debug for http::error::Error
impl Debug for http::extensions::Extensions
impl Debug for MaxSizeReached
impl Debug for HeaderName
impl Debug for InvalidHeaderName
impl Debug for HeaderValue
impl Debug for InvalidHeaderValue
impl Debug for ToStrError
impl Debug for InvalidMethod
impl Debug for Method
impl Debug for http::request::Builder
impl Debug for http::request::Parts
impl Debug for http::response::Builder
impl Debug for http::response::Parts
impl Debug for InvalidStatusCode
impl Debug for StatusCode
impl Debug for Authority
impl Debug for http::uri::builder::Builder
impl Debug for PathAndQuery
impl Debug for Scheme
impl Debug for InvalidUri
impl Debug for InvalidUriParts
impl Debug for http::uri::Parts
impl Debug for Uri
impl Debug for http::version::Version
impl Debug for Header<'_>
impl Debug for InvalidChunkSize
impl Debug for ParserConfig
impl Debug for hyper_util::client::legacy::client::Builder
impl Debug for hyper_util::client::legacy::client::Error
impl Debug for hyper_util::client::legacy::client::ResponseFuture
impl Debug for CaptureConnection
impl Debug for GaiAddrs
impl Debug for GaiFuture
impl Debug for GaiResolver
impl Debug for InvalidNameError
impl Debug for hyper_util::client::legacy::connect::dns::Name
impl Debug for HttpInfo
impl Debug for Connected
impl Debug for Intercept
impl Debug for Matcher
impl Debug for TokioExecutor
impl Debug for TokioTimer
impl Debug for hyper::body::incoming::Incoming
impl Debug for hyper::client::conn::http1::Builder
impl Debug for hyper::error::Error
impl Debug for ReasonPhrase
impl Debug for hyper::ext::Protocol
impl Debug for hyper::rt::io::ReadBuf<'_>
impl Debug for OnUpgrade
impl Debug for hyper::upgrade::Upgraded
impl Debug for CodePointInversionListULE
impl Debug for InvalidSetError
impl Debug for RangeError
impl Debug for CodePointInversionListAndStringListULE
impl Debug for CodePointTrieHeader
impl Debug for DataLocale
impl Debug for Other
impl Debug for icu_locale_core::extensions::private::other::Subtag
impl Debug for Private
impl Debug for icu_locale_core::extensions::Extensions
impl Debug for Fields
impl Debug for icu_locale_core::extensions::transform::key::Key
impl Debug for Transform
impl Debug for icu_locale_core::extensions::transform::value::Value
impl Debug for Attribute
impl Debug for icu_locale_core::extensions::unicode::attributes::Attributes
impl Debug for icu_locale_core::extensions::unicode::key::Key
impl Debug for Keywords
impl Debug for Unicode
impl Debug for SubdivisionId
impl Debug for SubdivisionSuffix
impl Debug for icu_locale_core::extensions::unicode::value::Value
impl Debug for LanguageIdentifier
impl Debug for Locale
impl Debug for CurrencyType
impl Debug for NumberingSystem
impl Debug for RegionOverride
impl Debug for RegionalSubdivision
impl Debug for TimeZoneShortId
impl Debug for LocalePreferences
impl Debug for Language
impl Debug for Region
impl Debug for icu_locale_core::subtags::script::Script
impl Debug for icu_locale_core::subtags::Subtag
impl Debug for Variant
impl Debug for Variants
impl Debug for CanonicalCombiningClassMap
impl Debug for CanonicalComposition
impl Debug for CanonicalDecomposition
impl Debug for icu_normalizer::provider::Baked
impl Debug for ComposingNormalizer
impl Debug for DecomposingNormalizer
impl Debug for Uts46Mapper
impl Debug for BidiMirroringGlyph
impl Debug for CodePointSetData
impl Debug for EmojiSetData
impl Debug for Alnum
impl Debug for Alphabetic
impl Debug for AsciiHexDigit
impl Debug for BasicEmoji
impl Debug for BidiClass
impl Debug for BidiControl
impl Debug for BidiMirrored
impl Debug for Blank
impl Debug for CanonicalCombiningClass
impl Debug for CaseIgnorable
impl Debug for CaseSensitive
impl Debug for Cased
impl Debug for ChangesWhenCasefolded
impl Debug for ChangesWhenCasemapped
impl Debug for ChangesWhenLowercased
impl Debug for ChangesWhenNfkcCasefolded
impl Debug for ChangesWhenTitlecased
impl Debug for ChangesWhenUppercased
impl Debug for Dash
impl Debug for DefaultIgnorableCodePoint
impl Debug for Deprecated
impl Debug for Diacritic
impl Debug for EastAsianWidth
impl Debug for Emoji
impl Debug for EmojiComponent
impl Debug for EmojiModifier
impl Debug for EmojiModifierBase
impl Debug for EmojiPresentation
impl Debug for ExtendedPictographic
impl Debug for Extender
impl Debug for FullCompositionExclusion
impl Debug for GeneralCategoryGroup
impl Debug for GeneralCategoryOutOfBoundsError
impl Debug for Graph
impl Debug for GraphemeBase
impl Debug for GraphemeClusterBreak
impl Debug for GraphemeExtend
impl Debug for GraphemeLink
impl Debug for HangulSyllableType
impl Debug for HexDigit
impl Debug for Hyphen
impl Debug for IdContinue
impl Debug for IdStart
impl Debug for Ideographic
impl Debug for IdsBinaryOperator
impl Debug for IdsTrinaryOperator
impl Debug for IndicSyllabicCategory
impl Debug for JoinControl
impl Debug for JoiningType
impl Debug for LineBreak
impl Debug for LogicalOrderException
impl Debug for Lowercase
impl Debug for Math
impl Debug for NfcInert
impl Debug for NfdInert
impl Debug for NfkcInert
impl Debug for NfkdInert
impl Debug for NoncharacterCodePoint
impl Debug for PatternSyntax
impl Debug for PatternWhiteSpace
impl Debug for PrependedConcatenationMark
impl Debug for Print
impl Debug for QuotationMark
impl Debug for Radical
impl Debug for RegionalIndicator
impl Debug for icu_properties::props::Script
impl Debug for SegmentStarter
impl Debug for SentenceBreak
impl Debug for SentenceTerminal
impl Debug for SoftDotted
impl Debug for TerminalPunctuation
impl Debug for UnifiedIdeograph
impl Debug for Uppercase
impl Debug for VariationSelector
impl Debug for VerticalOrientation
impl Debug for WhiteSpace
impl Debug for WordBreak
impl Debug for Xdigit
impl Debug for XidContinue
impl Debug for XidStart
impl Debug for icu_properties::provider::Baked
impl Debug for ScriptWithExtensions
impl Debug for BufferMarker
impl Debug for DataError
impl Debug for DataMarkerId
impl Debug for DataMarkerIdHash
impl Debug for DataMarkerInfo
impl Debug for AttributeParseError
impl Debug for DataMarkerAttributes
impl Debug for DataRequestMetadata
impl Debug for Cart
impl Debug for DataResponseMetadata
impl Debug for Errors
impl Debug for indexmap::TryReserveError
impl Debug for Ipv4AddrRange
impl Debug for Ipv6AddrRange
impl Debug for Ipv4Net
impl Debug for Ipv4Subnets
impl Debug for Ipv6Net
impl Debug for Ipv6Subnets
impl Debug for PrefixLenError
impl Debug for ipnet::parser::AddrParseError
impl Debug for UserinfoBuilder<'_>
impl Debug for CapacityOverflowError
impl Debug for iri_string::normalize::error::Error
impl Debug for iri_string::template::error::Error
impl Debug for SimpleContext
impl Debug for UriTemplateString
impl Debug for UriTemplateStr
impl Debug for iri_string::validate::Error
impl Debug for log::ParseLevelError
impl Debug for SetLoggerError
impl Debug for memchr::arch::all::memchr::One
impl Debug for memchr::arch::all::memchr::Three
impl Debug for memchr::arch::all::memchr::Two
impl Debug for memchr::arch::all::packedpair::Finder
impl Debug for Pair
impl Debug for memchr::arch::all::rabinkarp::Finder
impl Debug for memchr::arch::all::rabinkarp::FinderRev
impl Debug for memchr::arch::all::shiftor::Finder
impl Debug for memchr::arch::all::twoway::Finder
impl Debug for memchr::arch::all::twoway::FinderRev
impl Debug for memchr::arch::x86_64::avx2::memchr::One
impl Debug for memchr::arch::x86_64::avx2::memchr::Three
impl Debug for memchr::arch::x86_64::avx2::memchr::Two
impl Debug for memchr::arch::x86_64::avx2::packedpair::Finder
impl Debug for memchr::arch::x86_64::sse2::memchr::One
impl Debug for memchr::arch::x86_64::sse2::memchr::Three
impl Debug for memchr::arch::x86_64::sse2::memchr::Two
impl Debug for memchr::arch::x86_64::sse2::packedpair::Finder
impl Debug for FinderBuilder
impl Debug for FromStrError
impl Debug for Mime
impl Debug for mime_guess::Iter
impl Debug for IterRaw
impl Debug for MimeGuess
impl Debug for mio::event::event::Event
When the alternate flag is enabled this will print platform specific
details, for example the fields of the kevent
structure on platforms that
use kqueue(2)
. Note however that the output of this implementation is
not consider a part of the stable API.
impl Debug for Events
impl Debug for mio::interest::Interest
impl Debug for mio::net::tcp::listener::TcpListener
impl Debug for mio::net::tcp::stream::TcpStream
impl Debug for mio::net::udp::UdpSocket
impl Debug for mio::net::uds::datagram::UnixDatagram
impl Debug for mio::net::uds::listener::UnixListener
impl Debug for mio::net::uds::stream::UnixStream
impl Debug for mio::poll::Poll
impl Debug for Registry
impl Debug for mio::sys::unix::pipe::Receiver
impl Debug for mio::sys::unix::pipe::Sender
impl Debug for Token
impl Debug for mio::waker::Waker
impl Debug for native_tls::Error
impl Debug for native_tls::TlsConnector
impl Debug for OnceBool
impl Debug for OnceNonZeroUsize
impl Debug for ConversationItemCreate
impl Debug for ConversationItemDelete
impl Debug for ConversationItemTruncate
impl Debug for InputAudioBufferAppend
impl Debug for InputAudioBufferClear
impl Debug for InputAudioBufferCommit
impl Debug for ResponseCancel
impl Debug for ResponseCreate
impl Debug for SessionUpdate
impl Debug for ConversationCreated
impl Debug for ConversationItemCreated
impl Debug for ConversationItemDeleted
impl Debug for ConversationItemInputAudioTranscriptionCompleted
impl Debug for ConversationItemInputAudioTranscriptionFailed
impl Debug for ConversationItemTruncated
impl Debug for openai_api_rs::realtime::server_event::Error
impl Debug for InputAudioBufferCleared
impl Debug for InputAudioBufferCommited
impl Debug for InputAudioBufferSpeechStarted
impl Debug for InputAudioBufferSpeechStopped
impl Debug for RateLimitsUpdated
impl Debug for ResponseAudioDelta
impl Debug for ResponseAudioDone
impl Debug for ResponseAudioTranscriptDelta
impl Debug for ResponseAudioTranscriptDone
impl Debug for ResponseContentPartAdded
impl Debug for ResponseContentPartDone
impl Debug for ResponseCreated
impl Debug for ResponseDone
impl Debug for ResponseFunctionCallArgumentsDelta
impl Debug for ResponseFunctionCallArgumentsDone
impl Debug for ResponseOutputItemAdded
impl Debug for ResponseOutputItemDone
impl Debug for ResponseTextDelta
impl Debug for ResponseTextDone
impl Debug for SessionCreated
impl Debug for SessionUpdated
impl Debug for openai_api_rs::realtime::types::APIError
impl Debug for AudioTranscription
impl Debug for Conversation
impl Debug for FailedError
impl Debug for Item
impl Debug for ItemContent
impl Debug for RateLimit
impl Debug for openai_api_rs::realtime::types::Response
impl Debug for Session
impl Debug for openai_api_rs::realtime::types::Usage
impl Debug for AssistantFileObject
impl Debug for AssistantFileRequest
impl Debug for AssistantRequest
impl Debug for openai_api_rs::v1::assistant::CodeInterpreter
impl Debug for DeletionStatus
impl Debug for openai_api_rs::v1::assistant::FileSearch
impl Debug for FileSearchRankingOptions
impl Debug for ListAssistant
impl Debug for ListAssistantFile
impl Debug for openai_api_rs::v1::assistant::ToolResource
impl Debug for ToolsFileSearch
impl Debug for ToolsFileSearchObject
impl Debug for ToolsFunction
impl Debug for openai_api_rs::v1::assistant::VectorStores
impl Debug for AudioSpeechRequest
impl Debug for AudioSpeechResponse
impl Debug for AudioTranscriptionRequest
impl Debug for AudioTranscriptionResponse
impl Debug for AudioTranslationRequest
impl Debug for AudioTranslationResponse
impl Debug for BatchResponse
impl Debug for CreateBatchRequest
impl Debug for ListBatchResponse
impl Debug for openai_api_rs::v1::batch::Metadata
impl Debug for RequestCounts
impl Debug for ChatCompletionChoice
impl Debug for ChatCompletionMessage
impl Debug for ChatCompletionMessageForResponse
impl Debug for ChatCompletionRequest
impl Debug for ChatCompletionResponse
impl Debug for FinishDetails
impl Debug for ImageUrl
impl Debug for ImageUrlType
impl Debug for openai_api_rs::v1::chat_completion::Tool
impl Debug for ToolCall
impl Debug for ToolCallFunction
impl Debug for EmptyRequestBody
impl Debug for openai_api_rs::v1::common::Usage
impl Debug for CompletionChoice
impl Debug for CompletionRequest
impl Debug for CompletionResponse
impl Debug for LogprobResult
impl Debug for EditChoice
impl Debug for EditRequest
impl Debug for EditResponse
impl Debug for EmbeddingData
impl Debug for EmbeddingRequest
impl Debug for EmbeddingResponse
impl Debug for openai_api_rs::v1::embedding::Usage
impl Debug for FileData
impl Debug for FileDeleteRequest
impl Debug for FileDeleteResponse
impl Debug for FileListResponse
impl Debug for FileRetrieveResponse
impl Debug for FileUploadRequest
impl Debug for FileUploadResponse
impl Debug for CancelFineTuningJobRequest
impl Debug for CreateFineTuningJobRequest
impl Debug for FineTuningJobError
impl Debug for FineTuningJobEvent
impl Debug for FineTuningJobObject
impl Debug for HyperParameters
impl Debug for ListFineTuningJobEventsRequest
impl Debug for ListFineTuningJobsRequest
impl Debug for RetrieveFineTuningJobRequest
impl Debug for ImageData
impl Debug for ImageEditRequest
impl Debug for ImageEditResponse
impl Debug for ImageGenerationRequest
impl Debug for ImageGenerationResponse
impl Debug for ImageVariationRequest
impl Debug for ImageVariationResponse
impl Debug for openai_api_rs::v1::message::Attachment
impl Debug for openai_api_rs::v1::message::Content
impl Debug for openai_api_rs::v1::message::ContentText
impl Debug for CreateMessageRequest
impl Debug for ListMessage
impl Debug for ListMessageFile
impl Debug for MessageFileObject
impl Debug for MessageObject
impl Debug for ModifyMessageRequest
impl Debug for openai_api_rs::v1::message::Tool
impl Debug for CreateModerationRequest
impl Debug for CreateModerationResponse
impl Debug for ModerationCategories
impl Debug for ModerationCategoryScores
impl Debug for ModerationResult
impl Debug for CreateRunRequest
impl Debug for CreateThreadAndRunRequest
impl Debug for LastError
impl Debug for ListRun
impl Debug for ListRunStep
impl Debug for ModifyRunRequest
impl Debug for RunObject
impl Debug for RunStepObject
impl Debug for openai_api_rs::v1::thread::Attachment
impl Debug for openai_api_rs::v1::thread::CodeInterpreter
impl Debug for openai_api_rs::v1::thread::Content
impl Debug for openai_api_rs::v1::thread::ContentText
impl Debug for CreateThreadRequest
impl Debug for openai_api_rs::v1::thread::FileSearch
impl Debug for openai_api_rs::v1::thread::Message
impl Debug for ModifyThreadRequest
impl Debug for ThreadObject
impl Debug for openai_api_rs::v1::thread::Tool
impl Debug for openai_api_rs::v1::thread::ToolResource
impl Debug for openai_api_rs::v1::thread::VectorStores
impl Debug for Function
impl Debug for FunctionParameters
impl Debug for JSONSchemaDefine
impl Debug for KeyError
impl Debug for Asn1ObjectRef
impl Debug for Asn1StringRef
impl Debug for Asn1TimeRef
impl Debug for Asn1Type
impl Debug for TimeDiff
impl Debug for BigNum
impl Debug for BigNumRef
impl Debug for CMSOptions
impl Debug for DsaSig
impl Debug for Asn1Flag
impl Debug for openssl::error::Error
impl Debug for ErrorStack
impl Debug for DigestBytes
impl Debug for Nid
impl Debug for OcspCertStatus
impl Debug for OcspFlag
impl Debug for OcspResponseStatus
impl Debug for OcspRevokedStatus
impl Debug for KeyIvPair
impl Debug for Pkcs7Flags
impl Debug for openssl::pkey::Id
impl Debug for Padding
impl Debug for SrtpProfileId
impl Debug for SslConnector
impl Debug for openssl::ssl::error::Error
impl Debug for ErrorCode
impl Debug for AlpnError
impl Debug for CipherLists
impl Debug for ClientHelloResponse
impl Debug for ExtensionContext
impl Debug for ShutdownState
impl Debug for SniError
impl Debug for Ssl
impl Debug for SslAlert
impl Debug for SslCipherRef
impl Debug for SslContext
impl Debug for SslMode
impl Debug for SslOptions
impl Debug for SslRef
impl Debug for SslSessionCacheMode
impl Debug for SslVerifyMode
impl Debug for SslVersion
impl Debug for OpensslString
impl Debug for OpensslStringRef
impl Debug for CrlReason
impl Debug for GeneralNameRef
impl Debug for X509
impl Debug for X509NameEntryRef
impl Debug for X509NameRef
impl Debug for X509VerifyResult
impl Debug for X509CheckFlags
impl Debug for X509VerifyFlags
impl Debug for parking_lot::condvar::Condvar
impl Debug for parking_lot::condvar::WaitTimeoutResult
impl Debug for parking_lot::once::Once
impl Debug for ParkToken
impl Debug for UnparkResult
impl Debug for UnparkToken
impl Debug for PotentialCodePoint
impl Debug for PotentialUtf8
impl Debug for PotentialUtf16
impl Debug for AbsolutePath
impl Debug for CanonicalPath
impl Debug for CurrentPath
impl Debug for NativePath
impl Debug for Bernoulli
impl Debug for Open01
impl Debug for OpenClosed01
impl Debug for Alphanumeric
impl Debug for Standard
impl Debug for UniformChar
impl Debug for UniformDuration
impl Debug for ReadError
impl Debug for StepRng
impl Debug for StdRng
impl Debug for ThreadRng
impl Debug for ChaCha8Core
impl Debug for ChaCha8Rng
impl Debug for ChaCha12Core
impl Debug for ChaCha12Rng
impl Debug for ChaCha20Core
impl Debug for ChaCha20Rng
impl Debug for rand_core::error::Error
impl Debug for OsRng
impl Debug for KeyVal
impl Debug for Body
impl Debug for reqwest::async_impl::client::Client
impl Debug for ClientBuilder
impl Debug for Form
impl Debug for reqwest::async_impl::multipart::Part
impl Debug for reqwest::async_impl::request::Request
impl Debug for RequestBuilder
impl Debug for reqwest::async_impl::response::Response
impl Debug for reqwest::async_impl::upgrade::Upgraded
impl Debug for reqwest::dns::resolve::Name
impl Debug for reqwest::error::Error
impl Debug for NoProxy
impl Debug for Proxy
impl Debug for reqwest::redirect::Action
impl Debug for Policy
impl Debug for Certificate
impl Debug for reqwest::tls::Identity
impl Debug for TlsInfo
impl Debug for reqwest::tls::Version
impl Debug for AlgorithmIdentifier
impl Debug for rustls_pki_types::server_name::AddrParseError
impl Debug for InvalidDnsNameError
impl Debug for rustls_pki_types::server_name::Ipv4Addr
impl Debug for rustls_pki_types::server_name::Ipv6Addr
impl Debug for Der<'_>
impl Debug for EchConfigListBytes<'_>
impl Debug for InvalidSignature
impl Debug for PrivatePkcs1KeyDer<'_>
impl Debug for PrivatePkcs8KeyDer<'_>
impl Debug for PrivateSec1KeyDer<'_>
impl Debug for UnixTime
impl Debug for serde_json::error::Error
impl Debug for serde_json::map::Map<String, Value>
impl Debug for Number
impl Debug for CompactFormatter
impl Debug for Sha1Core
impl Debug for SigId
impl Debug for SockAddr
impl Debug for Socket
impl Debug for SockRef<'_>
impl Debug for Domain
impl Debug for socket2::Protocol
impl Debug for RecvFlags
impl Debug for TcpKeepalive
impl Debug for Type
impl Debug for TlsAcceptor
impl Debug for tokio_native_tls::TlsConnector
impl Debug for AnyDelimiterCodec
impl Debug for BytesCodec
impl Debug for tokio_util::codec::length_delimited::Builder
impl Debug for LengthDelimitedCodec
impl Debug for LengthDelimitedCodecError
impl Debug for LinesCodec
impl Debug for DropGuard
impl Debug for CancellationToken
impl Debug for WaitForCancellationFutureOwned
impl Debug for PollSemaphore
impl Debug for tokio::fs::dir_builder::DirBuilder
impl Debug for tokio::fs::file::File
impl Debug for tokio::fs::open_options::OpenOptions
impl Debug for tokio::fs::read_dir::DirEntry
impl Debug for tokio::fs::read_dir::ReadDir
impl Debug for TryIoError
impl Debug for tokio::io::interest::Interest
impl Debug for tokio::io::read_buf::ReadBuf<'_>
impl Debug for tokio::io::ready::Ready
impl Debug for tokio::io::stderr::Stderr
impl Debug for tokio::io::stdin::Stdin
impl Debug for tokio::io::stdout::Stdout
impl Debug for tokio::io::util::empty::Empty
impl Debug for DuplexStream
impl Debug for SimplexStream
impl Debug for tokio::io::util::repeat::Repeat
impl Debug for tokio::io::util::sink::Sink
impl Debug for tokio::net::tcp::listener::TcpListener
impl Debug for TcpSocket
impl Debug for tokio::net::tcp::split_owned::OwnedReadHalf
impl Debug for tokio::net::tcp::split_owned::OwnedWriteHalf
impl Debug for tokio::net::tcp::split_owned::ReuniteError
impl Debug for tokio::net::tcp::stream::TcpStream
impl Debug for tokio::net::udp::UdpSocket
impl Debug for tokio::net::unix::datagram::socket::UnixDatagram
impl Debug for tokio::net::unix::listener::UnixListener
impl Debug for tokio::net::unix::pipe::OpenOptions
impl Debug for tokio::net::unix::pipe::Receiver
impl Debug for tokio::net::unix::pipe::Sender
impl Debug for UnixSocket
impl Debug for tokio::net::unix::socketaddr::SocketAddr
impl Debug for tokio::net::unix::split_owned::OwnedReadHalf
impl Debug for tokio::net::unix::split_owned::OwnedWriteHalf
impl Debug for tokio::net::unix::split_owned::ReuniteError
impl Debug for tokio::net::unix::stream::UnixStream
impl Debug for tokio::net::unix::ucred::UCred
impl Debug for tokio::process::Child
impl Debug for tokio::process::ChildStderr
impl Debug for tokio::process::ChildStdin
impl Debug for tokio::process::ChildStdout
impl Debug for tokio::process::Command
impl Debug for tokio::runtime::builder::Builder
impl Debug for Handle
impl Debug for TryCurrentError
impl Debug for RuntimeMetrics
impl Debug for Runtime
impl Debug for tokio::runtime::task::abort::AbortHandle
impl Debug for JoinError
impl Debug for tokio::runtime::task::id::Id
impl Debug for Signal
impl Debug for SignalKind
impl Debug for tokio::sync::barrier::Barrier
impl Debug for tokio::sync::barrier::BarrierWaitResult
impl Debug for AcquireError
impl Debug for tokio::sync::mutex::TryLockError
impl Debug for Notify
impl Debug for tokio::sync::oneshot::error::RecvError
impl Debug for OwnedSemaphorePermit
impl Debug for Semaphore
impl Debug for tokio::sync::watch::error::RecvError
impl Debug for LocalEnterGuard
impl Debug for LocalSet
impl Debug for tokio::time::error::Elapsed
impl Debug for tokio::time::error::Error
impl Debug for tokio::time::instant::Instant
impl Debug for Interval
impl Debug for Sleep
impl Debug for GrpcEosErrorsAsFailures
impl Debug for GrpcErrorsAsFailures
impl Debug for StatusInRangeAsFailures
impl Debug for ServerErrorsAsFailures
impl Debug for FilterCredentials
impl Debug for tower_http::follow_redirect::policy::limited::Limited
impl Debug for SameOrigin
impl Debug for tower_layer::identity::Identity
impl Debug for tower::timeout::error::Elapsed
impl Debug for TimeoutLayer
impl Debug for tower::util::optional::error::None
impl Debug for DefaultCallsite
impl Debug for Identifier
impl Debug for DefaultGuard
impl Debug for Dispatch
impl Debug for SetGlobalDefaultError
impl Debug for WeakDispatch
impl Debug for tracing_core::field::Empty
impl Debug for Field
impl Debug for FieldSet
impl Debug for tracing_core::field::Iter
impl Debug for Kind
impl Debug for tracing_core::metadata::Level
impl Debug for tracing_core::metadata::LevelFilter
impl Debug for tracing_core::metadata::ParseLevelError
impl Debug for ParseLevelFilterError
impl Debug for Current
impl Debug for tracing_core::span::Id
impl Debug for tracing_core::subscriber::Interest
impl Debug for NoSubscriber
impl Debug for EnteredSpan
impl Debug for Span
impl Debug for ClientRequestBuilder
impl Debug for NoCallback
impl Debug for tungstenite::protocol::frame::frame::Frame
impl Debug for FrameHeader
impl Debug for WebSocketConfig
impl Debug for WebSocketContext
impl Debug for ATerm
impl Debug for B0
impl Debug for B1
impl Debug for Z0
impl Debug for Equal
impl Debug for Greater
impl Debug for Less
impl Debug for UTerm
impl Debug for OpaqueOrigin
impl Debug for Url
Debug the serialization of this URL.
impl Debug for Utf8CharsError
impl Debug for Incomplete
impl Debug for Closed
impl Debug for Giver
impl Debug for Taker
impl Debug for LengthHint
impl Debug for writeable::Part
impl Debug for zerocopy::error::AllocError
impl Debug for AsciiProbeResult
impl Debug for CharULE
impl Debug for Index8
impl Debug for Index16
impl Debug for Index32
impl Debug for Arguments<'_>
impl Debug for llm_tools::ser::core::fmt::Error
impl Debug for FormattingOptions
impl Debug for dyn Any
impl Debug for dyn Any + Send
impl Debug for dyn Any + Sync + Send
impl Debug for dyn Value
impl<'a> Debug for Unexpected<'a>
impl<'a> Debug for Utf8Pattern<'a>
impl<'a> Debug for Component<'a>
impl<'a> Debug for Prefix<'a>
impl<'a> Debug for Utf8Component<'a>
impl<'a> Debug for Utf8Prefix<'a>
impl<'a> Debug for IndexVecIter<'a>
impl<'a> Debug for PrivateKeyDer<'a>
impl<'a> Debug for TargetAddr<'a>
impl<'a> Debug for utf8::DecodeError<'a>
impl<'a> Debug for BufReadDecoderError<'a>
impl<'a> Debug for llm_tools::ser::core::error::Request<'a>
impl<'a> Debug for Source<'a>
impl<'a> Debug for llm_tools::ser::core::ffi::c_str::Bytes<'a>
impl<'a> Debug for BorrowedCursor<'a>
impl<'a> Debug for Location<'a>
impl<'a> Debug for PanicInfo<'a>
impl<'a> Debug for EscapeAscii<'a>
impl<'a> Debug for CharSearcher<'a>
impl<'a> Debug for llm_tools::ser::core::str::Bytes<'a>
impl<'a> Debug for CharIndices<'a>
impl<'a> Debug for llm_tools::ser::core::str::EscapeDebug<'a>
impl<'a> Debug for llm_tools::ser::core::str::EscapeDefault<'a>
impl<'a> Debug for llm_tools::ser::core::str::EscapeUnicode<'a>
impl<'a> Debug for llm_tools::ser::core::str::Lines<'a>
impl<'a> Debug for LinesAny<'a>
impl<'a> Debug for SplitAsciiWhitespace<'a>
impl<'a> Debug for SplitWhitespace<'a>
impl<'a> Debug for Utf8Chunk<'a>
impl<'a> Debug for ContextBuilder<'a>
impl<'a> Debug for IoSlice<'a>
impl<'a> Debug for IoSliceMut<'a>
impl<'a> Debug for std::net::tcp::Incoming<'a>
impl<'a> Debug for SocketAncillary<'a>
impl<'a> Debug for std::os::unix::net::listener::Incoming<'a>
impl<'a> Debug for PanicHookInfo<'a>
impl<'a> Debug for Ancestors<'a>
impl<'a> Debug for PrefixComponent<'a>
impl<'a> Debug for CommandArgs<'a>
impl<'a> Debug for CommandEnvs<'a>
impl<'a> Debug for Utf8Ancestors<'a>
impl<'a> Debug for Utf8Components<'a>
impl<'a> Debug for Utf8PrefixComponent<'a>
impl<'a> Debug for data_encoding::Display<'a>
impl<'a> Debug for Encoder<'a>
impl<'a> Debug for ByteSerialize<'a>
impl<'a> Debug for format_tools::format::string::private::Lines<'a>
impl<'a> Debug for LinesWithLimit<'a>
impl<'a> Debug for WakerRef<'a>
impl<'a> Debug for ReadBufCursor<'a>
impl<'a> Debug for CanonicalCombiningClassMapBorrowed<'a>
impl<'a> Debug for CanonicalCompositionBorrowed<'a>
impl<'a> Debug for CanonicalDecompositionBorrowed<'a>
impl<'a> Debug for ComposingNormalizerBorrowed<'a>
impl<'a> Debug for DecomposingNormalizerBorrowed<'a>
impl<'a> Debug for Uts46MapperBorrowed<'a>
impl<'a> Debug for CodePointSetDataBorrowed<'a>
impl<'a> Debug for EmojiSetDataBorrowed<'a>
impl<'a> Debug for ScriptExtensionsSet<'a>
impl<'a> Debug for ScriptWithExtensionsBorrowed<'a>
impl<'a> Debug for DataIdentifierBorrowed<'a>
impl<'a> Debug for DataRequest<'a>
impl<'a> Debug for iri_string::build::Builder<'a>
impl<'a> Debug for PortBuilder<'a>
impl<'a> Debug for AuthorityComponents<'a>
impl<'a> Debug for VarName<'a>
impl<'a> Debug for UriTemplateVariables<'a>
impl<'a> Debug for log::Metadata<'a>
impl<'a> Debug for MetadataBuilder<'a>
impl<'a> Debug for log::Record<'a>
impl<'a> Debug for RecordBuilder<'a>
impl<'a> Debug for MimeIter<'a>
impl<'a> Debug for mime::Name<'a>
impl<'a> Debug for Params<'a>
impl<'a> Debug for mio::event::events::Iter<'a>
impl<'a> Debug for SourceFd<'a>
impl<'a> Debug for PercentDecode<'a>
impl<'a> Debug for Attempt<'a>
impl<'a> Debug for DnsName<'a>
impl<'a> Debug for CertificateDer<'a>
impl<'a> Debug for CertificateRevocationListDer<'a>
impl<'a> Debug for CertificateSigningRequestDer<'a>
impl<'a> Debug for SubjectPublicKeyInfoDer<'a>
impl<'a> Debug for TrustAnchor<'a>
impl<'a> Debug for PrettyFormatter<'a>
impl<'a> Debug for MaybeUninitSlice<'a>
impl<'a> Debug for WaitForCancellationFuture<'a>
impl<'a> Debug for tokio::net::tcp::split::ReadHalf<'a>
impl<'a> Debug for tokio::net::tcp::split::WriteHalf<'a>
impl<'a> Debug for tokio::net::unix::split::ReadHalf<'a>
impl<'a> Debug for tokio::net::unix::split::WriteHalf<'a>
impl<'a> Debug for EnterGuard<'a>
impl<'a> Debug for Notified<'a>
impl<'a> Debug for SemaphorePermit<'a>
impl<'a> Debug for tracing_core::event::Event<'a>
impl<'a> Debug for ValueSet<'a>
impl<'a> Debug for tracing_core::metadata::Metadata<'a>
impl<'a> Debug for tracing_core::span::Attributes<'a>
impl<'a> Debug for tracing_core::span::Record<'a>
impl<'a> Debug for Entered<'a>
impl<'a> Debug for PathSegmentsMut<'a>
impl<'a> Debug for UrlQuery<'a>
impl<'a> Debug for Utf8CharIndices<'a>
impl<'a> Debug for ErrorReportingUtf8Chars<'a>
impl<'a> Debug for Utf8Chars<'a>
impl<'a> Debug for ZeroAsciiIgnoreCaseTrieCursor<'a>
impl<'a> Debug for ZeroTrieSimpleAsciiCursor<'a>
impl<'a, 'b> Debug for CharSliceSearcher<'a, 'b>
impl<'a, 'b> Debug for StrSearcher<'a, 'b>
impl<'a, 'b, const N: usize> Debug for CharArrayRefSearcher<'a, 'b, N>
impl<'a, 'f> Debug for VaList<'a, 'f>where
'f: 'a,
impl<'a, 'h> Debug for memchr::arch::all::memchr::OneIter<'a, 'h>
impl<'a, 'h> Debug for memchr::arch::all::memchr::ThreeIter<'a, 'h>
impl<'a, 'h> Debug for memchr::arch::all::memchr::TwoIter<'a, 'h>
impl<'a, 'h> Debug for memchr::arch::x86_64::avx2::memchr::OneIter<'a, 'h>
impl<'a, 'h> Debug for memchr::arch::x86_64::avx2::memchr::ThreeIter<'a, 'h>
impl<'a, 'h> Debug for memchr::arch::x86_64::avx2::memchr::TwoIter<'a, 'h>
impl<'a, 'h> Debug for memchr::arch::x86_64::sse2::memchr::OneIter<'a, 'h>
impl<'a, 'h> Debug for memchr::arch::x86_64::sse2::memchr::ThreeIter<'a, 'h>
impl<'a, 'h> Debug for memchr::arch::x86_64::sse2::memchr::TwoIter<'a, 'h>
impl<'a, A> Debug for llm_tools::ser::core::option::Iter<'a, A>where
A: Debug + 'a,
impl<'a, A> Debug for llm_tools::ser::core::option::IterMut<'a, A>where
A: Debug + 'a,
impl<'a, E> Debug for BytesDeserializer<'a, E>
impl<'a, E> Debug for CowStrDeserializer<'a, E>
impl<'a, E> Debug for StrDeserializer<'a, E>
impl<'a, Fut> Debug for futures_util::stream::futures_unordered::iter::Iter<'a, Fut>
impl<'a, Fut> Debug for futures_util::stream::futures_unordered::iter::IterMut<'a, Fut>
impl<'a, Fut> Debug for IterPinMut<'a, Fut>where
Fut: Debug,
impl<'a, Fut> Debug for IterPinRef<'a, Fut>where
Fut: Debug,
impl<'a, I> Debug for ByRefSized<'a, I>where
I: Debug,
impl<'a, I, A> Debug for alloc::vec::splice::Splice<'a, I, A>
impl<'a, K0, K1, V> Debug for ZeroMap2dBorrowed<'a, K0, K1, V>
impl<'a, K0, K1, V> Debug for ZeroMap2d<'a, K0, K1, V>
impl<'a, K, V> Debug for ZeroMapBorrowed<'a, K, V>
impl<'a, K, V> Debug for ZeroMap<'a, K, V>
impl<'a, P> Debug for MatchIndices<'a, P>
impl<'a, P> Debug for Matches<'a, P>
impl<'a, P> Debug for RMatchIndices<'a, P>
impl<'a, P> Debug for RMatches<'a, P>
impl<'a, P> Debug for llm_tools::ser::core::str::RSplit<'a, P>
impl<'a, P> Debug for llm_tools::ser::core::str::RSplitN<'a, P>
impl<'a, P> Debug for RSplitTerminator<'a, P>
impl<'a, P> Debug for llm_tools::ser::core::str::Split<'a, P>
impl<'a, P> Debug for llm_tools::ser::core::str::SplitInclusive<'a, P>
impl<'a, P> Debug for llm_tools::ser::core::str::SplitN<'a, P>
impl<'a, P> Debug for SplitTerminator<'a, P>
impl<'a, R, G, T> Debug for MappedReentrantMutexGuard<'a, R, G, T>
impl<'a, R, G, T> Debug for ReentrantMutexGuard<'a, R, G, T>
impl<'a, R, T> Debug for lock_api::mutex::MappedMutexGuard<'a, R, T>
impl<'a, R, T> Debug for lock_api::mutex::MutexGuard<'a, R, T>
impl<'a, R, T> Debug for lock_api::rwlock::MappedRwLockReadGuard<'a, R, T>
impl<'a, R, T> Debug for lock_api::rwlock::MappedRwLockWriteGuard<'a, R, T>
impl<'a, R, T> Debug for lock_api::rwlock::RwLockReadGuard<'a, R, T>
impl<'a, R, T> Debug for RwLockUpgradableReadGuard<'a, R, T>
impl<'a, R, T> Debug for lock_api::rwlock::RwLockWriteGuard<'a, R, T>
impl<'a, S> Debug for FixedBaseResolver<'a, S>
impl<'a, S, C> Debug for Expanded<'a, S, C>
impl<'a, S, T> Debug for SliceChooseIter<'a, S, T>
impl<'a, Si, Item> Debug for Close<'a, Si, Item>
impl<'a, Si, Item> Debug for Feed<'a, Si, Item>
impl<'a, Si, Item> Debug for Flush<'a, Si, Item>
impl<'a, Si, Item> Debug for Send<'a, Si, Item>
impl<'a, Src> Debug for MappedToUri<'a, Src>
impl<'a, St> Debug for futures_util::stream::select_all::Iter<'a, St>
impl<'a, St> Debug for futures_util::stream::select_all::IterMut<'a, St>
impl<'a, St> Debug for Next<'a, St>
impl<'a, St> Debug for SelectNextSome<'a, St>
impl<'a, St> Debug for TryNext<'a, St>
impl<'a, T> Debug for http::header::map::Entry<'a, T>where
T: Debug + 'a,
impl<'a, T> Debug for llm_tools::ser::core::result::Iter<'a, T>where
T: Debug + 'a,
impl<'a, T> Debug for llm_tools::ser::core::result::IterMut<'a, T>where
T: Debug + 'a,
impl<'a, T> Debug for llm_tools::ser::core::slice::Chunks<'a, T>where
T: Debug + 'a,
impl<'a, T> Debug for ChunksExact<'a, T>where
T: Debug + 'a,
impl<'a, T> Debug for ChunksExactMut<'a, T>where
T: Debug + 'a,
impl<'a, T> Debug for ChunksMut<'a, T>where
T: Debug + 'a,
impl<'a, T> Debug for RChunks<'a, T>where
T: Debug + 'a,
impl<'a, T> Debug for RChunksExact<'a, T>where
T: Debug + 'a,
impl<'a, T> Debug for RChunksExactMut<'a, T>where
T: Debug + 'a,
impl<'a, T> Debug for RChunksMut<'a, T>where
T: Debug + 'a,
impl<'a, T> Debug for Windows<'a, T>where
T: Debug + 'a,
impl<'a, T> Debug for alloc::collections::btree::set::Range<'a, T>where
T: Debug + 'a,
impl<'a, T> Debug for std::sync::mpmc::Iter<'a, T>where
T: Debug + 'a,
impl<'a, T> Debug for std::sync::mpmc::TryIter<'a, T>where
T: Debug + 'a,
impl<'a, T> Debug for std::sync::mpsc::Iter<'a, T>where
T: Debug + 'a,
impl<'a, T> Debug for std::sync::mpsc::TryIter<'a, T>where
T: Debug + 'a,
impl<'a, T> Debug for Cancellation<'a, T>where
T: Debug,
impl<'a, T> Debug for http_body_util::combinators::frame::Frame<'a, T>
impl<'a, T> Debug for http::header::map::Drain<'a, T>where
T: Debug,
impl<'a, T> Debug for GetAll<'a, T>where
T: Debug,
impl<'a, T> Debug for http::header::map::Iter<'a, T>where
T: Debug,
impl<'a, T> Debug for http::header::map::IterMut<'a, T>where
T: Debug,
impl<'a, T> Debug for http::header::map::Keys<'a, T>where
T: Debug,
impl<'a, T> Debug for http::header::map::OccupiedEntry<'a, T>where
T: Debug,
impl<'a, T> Debug for http::header::map::VacantEntry<'a, T>where
T: Debug,
impl<'a, T> Debug for ValueDrain<'a, T>where
T: Debug,
impl<'a, T> Debug for ValueIter<'a, T>where
T: Debug,
impl<'a, T> Debug for ValueIterMut<'a, T>where
T: Debug,
impl<'a, T> Debug for http::header::map::Values<'a, T>where
T: Debug,
impl<'a, T> Debug for http::header::map::ValuesMut<'a, T>where
T: Debug,
impl<'a, T> Debug for CodePointMapDataBorrowed<'a, T>
impl<'a, T> Debug for PropertyNamesLongBorrowed<'a, T>where
T: Debug + NamedEnumeratedProperty,
<T as NamedEnumeratedProperty>::DataStructLongBorrowed<'a>: Debug,
impl<'a, T> Debug for PropertyNamesShortBorrowed<'a, T>where
T: Debug + NamedEnumeratedProperty,
<T as NamedEnumeratedProperty>::DataStructShortBorrowed<'a>: Debug,
impl<'a, T> Debug for PropertyParserBorrowed<'a, T>where
T: Debug,
impl<'a, T> Debug for Built<'a, T>
impl<'a, T> Debug for OnceRef<'a, T>
impl<'a, T> Debug for rand::distributions::slice::Slice<'a, T>where
T: Debug,
impl<'a, T> Debug for slab::VacantEntry<'a, T>where
T: Debug,
impl<'a, T> Debug for smallvec::Drain<'a, T>
impl<'a, T> Debug for AsyncFdReadyGuard<'a, T>
impl<'a, T> Debug for AsyncFdReadyMutGuard<'a, T>
impl<'a, T> Debug for tokio::sync::mutex::MappedMutexGuard<'a, T>
impl<'a, T> Debug for tokio::sync::rwlock::read_guard::RwLockReadGuard<'a, T>
impl<'a, T> Debug for tokio::sync::rwlock::write_guard::RwLockWriteGuard<'a, T>
impl<'a, T> Debug for RwLockMappedWriteGuard<'a, T>
impl<'a, T> Debug for tokio::sync::watch::Ref<'a, T>where
T: Debug,
impl<'a, T> Debug for Locked<'a, T>where
T: Debug,
impl<'a, T> Debug for ZeroSliceIter<'a, T>
impl<'a, T, A> Debug for alloc::collections::binary_heap::Drain<'a, T, A>
impl<'a, T, A> Debug for DrainSorted<'a, T, A>
impl<'a, T, F> Debug for VarZeroSliceIter<'a, T, F>
impl<'a, T, I> Debug for Ptr<'a, T, I>where
T: 'a + ?Sized,
I: Invariants,
impl<'a, T, Marker> Debug for OptionalCow<'a, T, Marker>
impl<'a, T, P> Debug for ChunkBy<'a, T, P>where
T: 'a + Debug,
impl<'a, T, P> Debug for ChunkByMut<'a, T, P>where
T: 'a + Debug,
impl<'a, T, Request> Debug for tower::util::ready::Ready<'a, T, Request>where
T: Debug,
impl<'a, T, const N: usize> Debug for llm_tools::ser::core::slice::ArrayChunks<'a, T, N>where
T: Debug + 'a,
impl<'a, T, const N: usize> Debug for ArrayChunksMut<'a, T, N>where
T: Debug + 'a,
impl<'a, T, const N: usize> Debug for ArrayWindows<'a, T, N>where
T: Debug + 'a,
impl<'a, V> Debug for VarZeroCow<'a, V>
impl<'a, const N: usize> Debug for CharArraySearcher<'a, N>
impl<'callback> Debug for Printer<'callback>
impl<'data> Debug for PropertyCodePointSet<'data>
impl<'data> Debug for PropertyUnicodeSet<'data>
impl<'data> Debug for InputExtract<'data>
impl<'data> Debug for Char16Trie<'data>
impl<'data> Debug for CodePointInversionList<'data>
impl<'data> Debug for CodePointInversionListAndStringList<'data>
impl<'data> Debug for CanonicalCompositions<'data>
impl<'data> Debug for DecompositionData<'data>
impl<'data> Debug for DecompositionTables<'data>
impl<'data> Debug for NonRecursiveDecompositionSupplement<'data>
impl<'data> Debug for PropertyEnumToValueNameLinearMap<'data>
impl<'data> Debug for PropertyEnumToValueNameSparseMap<'data>
impl<'data> Debug for PropertyScriptToIcuScriptMap<'data>
impl<'data> Debug for PropertyValueNameToEnumMap<'data>
impl<'data> Debug for ScriptWithExtensionsProperty<'data>
impl<'data, I> Debug for Composition<'data, I>
impl<'data, I> Debug for Decomposition<'data, I>
impl<'data, T> Debug for PropertyCodePointMap<'data, T>
impl<'de, E> Debug for BorrowedBytesDeserializer<'de, E>
impl<'de, E> Debug for BorrowedStrDeserializer<'de, E>
impl<'de, I, E> Debug for MapDeserializer<'de, I, E>
impl<'e, E, R> Debug for DecoderReader<'e, E, R>
impl<'e, E, W> Debug for EncoderWriter<'e, E, W>
impl<'f> Debug for VaListImpl<'f>
impl<'h> Debug for Memchr2<'h>
impl<'h> Debug for Memchr3<'h>
impl<'h> Debug for Memchr<'h>
impl<'h, 'n> Debug for FindIter<'h, 'n>
impl<'h, 'n> Debug for FindRevIter<'h, 'n>
impl<'headers, 'buf> Debug for httparse::Request<'headers, 'buf>
impl<'headers, 'buf> Debug for httparse::Response<'headers, 'buf>
impl<'l, 'a, K0, K1, V> Debug for ZeroMap2dCursor<'l, 'a, K0, K1, V>
impl<'label> Debug for ColDescriptor<'label>
impl<'n> Debug for memchr::memmem::Finder<'n>
impl<'n> Debug for memchr::memmem::FinderRev<'n>
impl<'name, 'bufs, 'control> Debug for MsgHdr<'name, 'bufs, 'control>
impl<'name, 'bufs, 'control> Debug for MsgHdrMut<'name, 'bufs, 'control>
impl<'scope, T> Debug for ScopedJoinHandle<'scope, T>
impl<'t> Debug for CloseFrame<'t>
impl<'table, Table, RowKey, Row, CellKey> Debug for AsTable<'table, Table, RowKey, Row, CellKey>
impl<'trie, T> Debug for CodePointTrie<'trie, T>
impl<A> Debug for EnumAccessDeserializer<A>where
A: Debug,
impl<A> Debug for MapAccessDeserializer<A>where
A: Debug,
impl<A> Debug for SeqAccessDeserializer<A>where
A: Debug,
impl<A> Debug for llm_tools::ser::core::iter::Repeat<A>where
A: Debug,
impl<A> Debug for RepeatN<A>where
A: Debug,
impl<A> Debug for llm_tools::ser::core::option::IntoIter<A>where
A: Debug,
impl<A> Debug for IterRange<A>where
A: Debug,
impl<A> Debug for IterRangeFrom<A>where
A: Debug,
impl<A> Debug for IterRangeInclusive<A>where
A: Debug,
impl<A> Debug for smallvec::IntoIter<A>
impl<A> Debug for SmallVec<A>
impl<A, B> Debug for futures_util::future::either::Either<A, B>
impl<A, B> Debug for tower::util::either::Either<A, B>
impl<A, B> Debug for llm_tools::ser::core::iter::Chain<A, B>
impl<A, B> Debug for llm_tools::ser::core::iter::Zip<A, B>
impl<A, B> Debug for futures_util::future::select::Select<A, B>
impl<A, B> Debug for TrySelect<A, B>
impl<A, B> Debug for And<A, B>
impl<A, B> Debug for Or<A, B>
impl<A, B> Debug for Tuple2ULE<A, B>
impl<A, B> Debug for VarTuple<A, B>
impl<A, B, C> Debug for Tuple3ULE<A, B, C>
impl<A, B, C, D> Debug for Tuple4ULE<A, B, C, D>
impl<A, B, C, D, E> Debug for Tuple5ULE<A, B, C, D, E>
impl<A, B, C, D, E, F> Debug for Tuple6ULE<A, B, C, D, E, F>
impl<A, B, C, D, E, F, Format> Debug for Tuple6VarULE<A, B, C, D, E, F, Format>
impl<A, B, C, D, E, Format> Debug for Tuple5VarULE<A, B, C, D, E, Format>
impl<A, B, C, D, Format> Debug for Tuple4VarULE<A, B, C, D, Format>
impl<A, B, C, Format> Debug for Tuple3VarULE<A, B, C, Format>
impl<A, B, Format> Debug for Tuple2VarULE<A, B, Format>
impl<A, S, V> Debug for ConvertError<A, S, V>
impl<A, V> Debug for VarTupleULE<A, V>
impl<B> Debug for Cow<'_, B>
impl<B> Debug for std::io::Lines<B>where
B: Debug,
impl<B> Debug for std::io::Split<B>where
B: Debug,
impl<B> Debug for Flag<B>where
B: Debug,
impl<B> Debug for Reader<B>where
B: Debug,
impl<B> Debug for Writer<B>where
B: Debug,
impl<B> Debug for ReadySendRequest<B>
impl<B> Debug for h2::client::SendRequest<B>where
B: Buf,
impl<B> Debug for SendPushedResponse<B>
impl<B> Debug for SendResponse<B>
impl<B> Debug for SendStream<B>where
B: Debug,
impl<B> Debug for Collected<B>where
B: Debug,
impl<B> Debug for http_body_util::limited::Limited<B>where
B: Debug,
impl<B> Debug for BodyDataStream<B>where
B: Debug,
impl<B> Debug for BodyStream<B>where
B: Debug,
impl<B> Debug for hyper::client::conn::http1::SendRequest<B>
impl<B> Debug for hyper::client::conn::http2::SendRequest<B>
impl<B, C> Debug for ControlFlow<B, C>
impl<B, F> Debug for http_body_util::combinators::map_err::MapErr<B, F>where
B: Debug,
impl<B, F> Debug for MapFrame<B, F>where
B: Debug,
impl<BlockSize, Kind> Debug for BlockBuffer<BlockSize, Kind>where
BlockSize: Debug + ArrayLength<u8> + IsLess<UInt<UInt<UInt<UInt<UInt<UInt<UInt<UInt<UInt<UTerm, B1>, B0>, B0>, B0>, B0>, B0>, B0>, B0>, B0>>,
Kind: Debug + BufferKind,
<BlockSize as IsLess<UInt<UInt<UInt<UInt<UInt<UInt<UInt<UInt<UInt<UTerm, B1>, B0>, B0>, B0>, B0>, B0>, B0>, B0>, B0>>>::Output: NonZero,
impl<C0, C1> Debug for EitherCart<C0, C1>
impl<C> Debug for SocksV4<C>where
C: Debug,
impl<C> Debug for SocksV5<C>where
C: Debug,
impl<C> Debug for Tunnel<C>where
C: Debug,
impl<C> Debug for CartableOptionPointer<C>
impl<C, B> Debug for hyper_util::client::legacy::client::Client<C, B>
impl<C, F> Debug for MapFailureClass<C, F>where
C: Debug,
impl<D> Debug for http_body_util::empty::Empty<D>
impl<D> Debug for Full<D>where
D: Debug,
impl<D, E> Debug for BoxBody<D, E>
impl<D, E> Debug for UnsyncBoxBody<D, E>
impl<D, F, T, S> Debug for DistMap<D, F, T, S>
impl<D, R, T> Debug for DistIter<D, R, T>
impl<DataStruct> Debug for ErasedMarker<DataStruct>
impl<Definition> Debug for FormingEndClosure<Definition>where
Definition: FormerDefinitionTypes,
impl<Dyn> Debug for DynMetadata<Dyn>where
Dyn: ?Sized,
impl<E> Debug for BoolDeserializer<E>
impl<E> Debug for CharDeserializer<E>
impl<E> Debug for F32Deserializer<E>
impl<E> Debug for F64Deserializer<E>
impl<E> Debug for I8Deserializer<E>
impl<E> Debug for I16Deserializer<E>
impl<E> Debug for I32Deserializer<E>
impl<E> Debug for I64Deserializer<E>
impl<E> Debug for I128Deserializer<E>
impl<E> Debug for IsizeDeserializer<E>
impl<E> Debug for StringDeserializer<E>
impl<E> Debug for U8Deserializer<E>
impl<E> Debug for U16Deserializer<E>
impl<E> Debug for U32Deserializer<E>
impl<E> Debug for U64Deserializer<E>
impl<E> Debug for U128Deserializer<E>
impl<E> Debug for UnitDeserializer<E>
impl<E> Debug for UsizeDeserializer<E>
impl<E> Debug for Report<E>
impl<E, Context, Formed> Debug for BinaryHeapDefinitionTypes<E, Context, Formed>
impl<E, Context, Formed> Debug for BTreeSetDefinitionTypes<E, Context, Formed>
impl<E, Context, Formed> Debug for LinkedListDefinitionTypes<E, Context, Formed>
impl<E, Context, Formed> Debug for VectorDefinitionTypes<E, Context, Formed>
impl<E, Context, Formed> Debug for VecDequeDefinitionTypes<E, Context, Formed>
impl<E, Context, Formed, End> Debug for BinaryHeapDefinition<E, Context, Formed, End>where
E: Debug + Ord,
Context: Debug,
Formed: Debug,
End: Debug + FormingEnd<BinaryHeapDefinitionTypes<E, Context, Formed>>,
impl<E, Context, Formed, End> Debug for BTreeSetDefinition<E, Context, Formed, End>where
E: Debug,
Context: Debug,
Formed: Debug,
End: Debug + FormingEnd<BTreeSetDefinitionTypes<E, Context, Formed>>,
impl<E, Context, Formed, End> Debug for LinkedListDefinition<E, Context, Formed, End>where
E: Debug,
Context: Debug,
Formed: Debug,
End: Debug + FormingEnd<LinkedListDefinitionTypes<E, Context, Formed>>,
impl<E, Context, Formed, End> Debug for VectorDefinition<E, Context, Formed, End>where
E: Debug,
Context: Debug,
Formed: Debug,
End: Debug + FormingEnd<VectorDefinitionTypes<E, Context, Formed>>,
impl<E, Context, Formed, End> Debug for VecDequeDefinition<E, Context, Formed, End>where
E: Debug,
Context: Debug,
Formed: Debug,
End: Debug + FormingEnd<VecDequeDefinitionTypes<E, Context, Formed>>,
impl<E, Definition> Debug for CollectionFormer<E, Definition>where
Definition: FormerDefinition,
<Definition as FormerDefinition>::Storage: CollectionAdd<Entry = E>,
impl<Ex> Debug for hyper::client::conn::http2::Builder<Ex>where
Ex: Debug,
impl<F1, F2, N> Debug for AndThenFuture<F1, F2, N>where
F2: TryFuture,
impl<F1, F2, N> Debug for ThenFuture<F1, F2, N>
impl<F> Debug for llm_tools::ser::core::future::PollFn<F>
impl<F> Debug for llm_tools::ser::core::iter::FromFn<F>
impl<F> Debug for OnceWith<F>
impl<F> Debug for llm_tools::ser::core::iter::RepeatWith<F>
impl<F> Debug for CharPredicateSearcher<'_, F>
impl<F> Debug for futures_util::future::future::Flatten<F>
impl<F> Debug for FlattenStream<F>
impl<F> Debug for futures_util::future::future::IntoStream<F>
impl<F> Debug for JoinAll<F>
impl<F> Debug for futures_util::future::lazy::Lazy<F>where
F: Debug,
impl<F> Debug for OptionFuture<F>where
F: Debug,
impl<F> Debug for futures_util::future::poll_fn::PollFn<F>
impl<F> Debug for TryJoinAll<F>
impl<F> Debug for futures_util::stream::poll_fn::PollFn<F>
impl<F> Debug for futures_util::stream::repeat_with::RepeatWith<F>where
F: Debug,
impl<F> Debug for CloneBodyFn<F>
impl<F> Debug for RedirectFn<F>
impl<F> Debug for LayerFn<F>
impl<F> Debug for AndThenLayer<F>where
F: Debug,
impl<F> Debug for MapErrLayer<F>where
F: Debug,
impl<F> Debug for MapFutureLayer<F>
impl<F> Debug for MapRequestLayer<F>where
F: Debug,
impl<F> Debug for MapResponseLayer<F>where
F: Debug,
impl<F> Debug for MapResultLayer<F>where
F: Debug,
impl<F> Debug for ThenLayer<F>where
F: Debug,
impl<F> Debug for llm_tools::ser::core::fmt::FromFn<F>
impl<F> Debug for Fwhere
F: FnPtr,
impl<F, N> Debug for MapErrFuture<F, N>
impl<F, N> Debug for MapResponseFuture<F, N>
impl<F, N> Debug for MapResultFuture<F, N>
impl<F, S> Debug for FutureService<F, S>where
S: Debug,
impl<FailureClass, ClassifyEos> Debug for ClassifiedResponse<FailureClass, ClassifyEos>
impl<Fut1, Fut2> Debug for futures_util::future::join::Join<Fut1, Fut2>
impl<Fut1, Fut2> Debug for futures_util::future::try_future::TryFlatten<Fut1, Fut2>where
TryFlatten<Fut1, Fut2>: Debug,
impl<Fut1, Fut2> Debug for TryJoin<Fut1, Fut2>
impl<Fut1, Fut2, F> Debug for futures_util::future::future::Then<Fut1, Fut2, F>
impl<Fut1, Fut2, F> Debug for futures_util::future::try_future::AndThen<Fut1, Fut2, F>
impl<Fut1, Fut2, F> Debug for futures_util::future::try_future::OrElse<Fut1, Fut2, F>
impl<Fut1, Fut2, Fut3> Debug for Join3<Fut1, Fut2, Fut3>
impl<Fut1, Fut2, Fut3> Debug for TryJoin3<Fut1, Fut2, Fut3>
impl<Fut1, Fut2, Fut3, Fut4> Debug for Join4<Fut1, Fut2, Fut3, Fut4>
impl<Fut1, Fut2, Fut3, Fut4> Debug for TryJoin4<Fut1, Fut2, Fut3, Fut4>where
Fut1: TryFuture + Debug,
<Fut1 as TryFuture>::Ok: Debug,
<Fut1 as TryFuture>::Error: Debug,
Fut2: TryFuture + Debug,
<Fut2 as TryFuture>::Ok: Debug,
<Fut2 as TryFuture>::Error: Debug,
Fut3: TryFuture + Debug,
<Fut3 as TryFuture>::Ok: Debug,
<Fut3 as TryFuture>::Error: Debug,
Fut4: TryFuture + Debug,
<Fut4 as TryFuture>::Ok: Debug,
<Fut4 as TryFuture>::Error: Debug,
impl<Fut1, Fut2, Fut3, Fut4, Fut5> Debug for Join5<Fut1, Fut2, Fut3, Fut4, Fut5>
impl<Fut1, Fut2, Fut3, Fut4, Fut5> Debug for TryJoin5<Fut1, Fut2, Fut3, Fut4, Fut5>where
Fut1: TryFuture + Debug,
<Fut1 as TryFuture>::Ok: Debug,
<Fut1 as TryFuture>::Error: Debug,
Fut2: TryFuture + Debug,
<Fut2 as TryFuture>::Ok: Debug,
<Fut2 as TryFuture>::Error: Debug,
Fut3: TryFuture + Debug,
<Fut3 as TryFuture>::Ok: Debug,
<Fut3 as TryFuture>::Error: Debug,
Fut4: TryFuture + Debug,
<Fut4 as TryFuture>::Ok: Debug,
<Fut4 as TryFuture>::Error: Debug,
Fut5: TryFuture + Debug,
<Fut5 as TryFuture>::Ok: Debug,
<Fut5 as TryFuture>::Error: Debug,
impl<Fut> Debug for MaybeDone<Fut>
impl<Fut> Debug for TryMaybeDone<Fut>
impl<Fut> Debug for futures_util::future::future::catch_unwind::CatchUnwind<Fut>where
Fut: Debug,
impl<Fut> Debug for futures_util::future::future::fuse::Fuse<Fut>where
Fut: Debug,
impl<Fut> Debug for NeverError<Fut>
impl<Fut> Debug for UnitError<Fut>
impl<Fut> Debug for futures_util::future::select_all::SelectAll<Fut>where
Fut: Debug,
impl<Fut> Debug for SelectOk<Fut>where
Fut: Debug,
impl<Fut> Debug for IntoFuture<Fut>where
Fut: Debug,
impl<Fut> Debug for TryFlattenStream<Fut>
impl<Fut> Debug for FuturesOrdered<Fut>where
Fut: Future,
impl<Fut> Debug for futures_util::stream::futures_unordered::iter::IntoIter<Fut>
impl<Fut> Debug for FuturesUnordered<Fut>
impl<Fut> Debug for futures_util::stream::once::Once<Fut>where
Fut: Debug,
impl<Fut, E> Debug for futures_util::future::try_future::ErrInto<Fut, E>
impl<Fut, E> Debug for OkInto<Fut, E>
impl<Fut, F> Debug for futures_util::future::future::Inspect<Fut, F>where
Map<Fut, InspectFn<F>>: Debug,
impl<Fut, F> Debug for futures_util::future::future::Map<Fut, F>where
Map<Fut, F>: Debug,
impl<Fut, F> Debug for futures_util::future::try_future::InspectErr<Fut, F>
impl<Fut, F> Debug for futures_util::future::try_future::InspectOk<Fut, F>
impl<Fut, F> Debug for futures_util::future::try_future::MapErr<Fut, F>
impl<Fut, F> Debug for futures_util::future::try_future::MapOk<Fut, F>
impl<Fut, F> Debug for UnwrapOrElse<Fut, F>
impl<Fut, F, G> Debug for MapOkOrElse<Fut, F, G>
impl<Fut, Si> Debug for FlattenSink<Fut, Si>where
TryFlatten<Fut, Si>: Debug,
impl<Fut, T> Debug for MapInto<Fut, T>
impl<G> Debug for FromCoroutine<G>
impl<H> Debug for BuildHasherDefault<H>
impl<H> Debug for HasherRng<H>where
H: Debug,
impl<I> Debug for FromIter<I>where
I: Debug,
impl<I> Debug for DecodeUtf16<I>
impl<I> Debug for Cloned<I>where
I: Debug,
impl<I> Debug for Copied<I>where
I: Debug,
impl<I> Debug for llm_tools::ser::core::iter::Cycle<I>where
I: Debug,
impl<I> Debug for llm_tools::ser::core::iter::Enumerate<I>where
I: Debug,
impl<I> Debug for llm_tools::ser::core::iter::Fuse<I>where
I: Debug,
impl<I> Debug for Intersperse<I>
impl<I> Debug for llm_tools::ser::core::iter::Peekable<I>
impl<I> Debug for llm_tools::ser::core::iter::Skip<I>where
I: Debug,
impl<I> Debug for StepBy<I>where
I: Debug,
impl<I> Debug for llm_tools::ser::core::iter::Take<I>where
I: Debug,
impl<I> Debug for futures_util::stream::iter::Iter<I>where
I: Debug,
impl<I> Debug for WithHyperIo<I>where
I: Debug,
impl<I> Debug for WithTokioIo<I>where
I: Debug,
impl<I, E> Debug for SeqDeserializer<I, E>where
I: Debug,
impl<I, F> Debug for llm_tools::ser::core::iter::FilterMap<I, F>where
I: Debug,
impl<I, F> Debug for llm_tools::ser::core::iter::Inspect<I, F>where
I: Debug,
impl<I, F> Debug for llm_tools::ser::core::iter::Map<I, F>where
I: Debug,
impl<I, F, const N: usize> Debug for MapWindows<I, F, N>
impl<I, G> Debug for IntersperseWith<I, G>
impl<I, K, V, S> Debug for indexmap::map::iter::Splice<'_, I, K, V, S>
impl<I, P> Debug for llm_tools::ser::core::iter::Filter<I, P>where
I: Debug,
impl<I, P> Debug for MapWhile<I, P>where
I: Debug,
impl<I, P> Debug for llm_tools::ser::core::iter::SkipWhile<I, P>where
I: Debug,
impl<I, P> Debug for llm_tools::ser::core::iter::TakeWhile<I, P>where
I: Debug,
impl<I, St, F> Debug for llm_tools::ser::core::iter::Scan<I, St, F>
impl<I, T, S> Debug for indexmap::set::iter::Splice<'_, I, T, S>
impl<I, U> Debug for llm_tools::ser::core::iter::Flatten<I>
impl<I, U, F> Debug for llm_tools::ser::core::iter::FlatMap<I, U, F>
impl<I, const N: usize> Debug for llm_tools::ser::core::iter::ArrayChunks<I, N>
impl<Idx> Debug for llm_tools::ser::core::ops::Range<Idx>where
Idx: Debug,
impl<Idx> Debug for llm_tools::ser::core::ops::RangeFrom<Idx>where
Idx: Debug,
impl<Idx> Debug for llm_tools::ser::core::ops::RangeInclusive<Idx>where
Idx: Debug,
impl<Idx> Debug for RangeTo<Idx>where
Idx: Debug,
impl<Idx> Debug for RangeToInclusive<Idx>where
Idx: Debug,
impl<Idx> Debug for llm_tools::ser::core::range::Range<Idx>where
Idx: Debug,
impl<Idx> Debug for llm_tools::ser::core::range::RangeFrom<Idx>where
Idx: Debug,
impl<Idx> Debug for llm_tools::ser::core::range::RangeInclusive<Idx>where
Idx: Debug,
impl<In, T, U, E> Debug for BoxLayer<In, T, U, E>
impl<In, T, U, E> Debug for BoxCloneServiceLayer<In, T, U, E>
impl<In, T, U, E> Debug for BoxCloneSyncServiceLayer<In, T, U, E>
impl<Inner, Outer> Debug for tower_layer::stack::Stack<Inner, Outer>
impl<K> Debug for alloc::collections::btree::set::Cursor<'_, K>where
K: Debug,
impl<K> Debug for std::collections::hash::set::Drain<'_, K>where
K: Debug,
impl<K> Debug for std::collections::hash::set::IntoIter<K>where
K: Debug,
impl<K> Debug for std::collections::hash::set::Iter<'_, K>where
K: Debug,
impl<K> Debug for hashbrown::set::Iter<'_, K>where
K: Debug,
impl<K, A> Debug for alloc::collections::btree::set::CursorMut<'_, K, A>where
K: Debug,
impl<K, A> Debug for alloc::collections::btree::set::CursorMutKey<'_, K, A>where
K: Debug,
impl<K, A> Debug for hashbrown::set::Drain<'_, K, A>where
K: Debug,
A: Allocator,
impl<K, A> Debug for hashbrown::set::IntoIter<K, A>where
K: Debug,
A: Allocator,
impl<K, Context, Formed> Debug for HashSetDefinitionTypes<K, Context, Formed>
impl<K, Context, Formed, End> Debug for HashSetDefinition<K, Context, Formed, End>where
K: Debug + Eq + Hash,
Context: Debug,
Formed: Debug,
End: Debug + FormingEnd<HashSetDefinitionTypes<K, Context, Formed>>,
impl<K, E, Context, Formed> Debug for BTreeMapDefinitionTypes<K, E, Context, Formed>
impl<K, E, Context, Formed> Debug for HashMapDefinitionTypes<K, E, Context, Formed>
impl<K, E, Context, Formed, End> Debug for BTreeMapDefinition<K, E, Context, Formed, End>where
K: Debug + Ord,
E: Debug,
Context: Debug,
Formed: Debug,
End: Debug + FormingEnd<BTreeMapDefinitionTypes<K, E, Context, Formed>>,
impl<K, E, Context, Formed, End> Debug for HashMapDefinition<K, E, Context, Formed, End>where
K: Debug + Eq + Hash,
E: Debug,
Context: Debug,
Formed: Debug,
End: Debug + FormingEnd<HashMapDefinitionTypes<K, E, Context, Formed>>,
impl<K, F> Debug for std::collections::hash::set::ExtractIf<'_, K, F>where
K: Debug,
impl<K, Q, V, S, A> Debug for EntryRef<'_, '_, K, Q, V, S, A>
impl<K, Q, V, S, A> Debug for VacantEntryRef<'_, '_, K, Q, V, S, A>
impl<K, V> Debug for std::collections::hash::map::Entry<'_, K, V>
impl<K, V> Debug for indexmap::map::core::entry::Entry<'_, K, V>
impl<K, V> Debug for alloc::collections::btree::map::Cursor<'_, K, V>
impl<K, V> Debug for alloc::collections::btree::map::Iter<'_, K, V>
impl<K, V> Debug for alloc::collections::btree::map::IterMut<'_, K, V>
impl<K, V> Debug for alloc::collections::btree::map::Keys<'_, K, V>where
K: Debug,
impl<K, V> Debug for alloc::collections::btree::map::Range<'_, K, V>
impl<K, V> Debug for RangeMut<'_, K, V>
impl<K, V> Debug for alloc::collections::btree::map::Values<'_, K, V>where
V: Debug,
impl<K, V> Debug for alloc::collections::btree::map::ValuesMut<'_, K, V>where
V: Debug,
impl<K, V> Debug for std::collections::hash::map::Drain<'_, K, V>
impl<K, V> Debug for std::collections::hash::map::IntoIter<K, V>
impl<K, V> Debug for std::collections::hash::map::IntoKeys<K, V>where
K: Debug,
impl<K, V> Debug for std::collections::hash::map::IntoValues<K, V>where
V: Debug,
impl<K, V> Debug for std::collections::hash::map::Iter<'_, K, V>
impl<K, V> Debug for std::collections::hash::map::IterMut<'_, K, V>
impl<K, V> Debug for std::collections::hash::map::Keys<'_, K, V>where
K: Debug,
impl<K, V> Debug for std::collections::hash::map::OccupiedEntry<'_, K, V>
impl<K, V> Debug for std::collections::hash::map::OccupiedError<'_, K, V>
impl<K, V> Debug for std::collections::hash::map::VacantEntry<'_, K, V>where
K: Debug,
impl<K, V> Debug for std::collections::hash::map::Values<'_, K, V>where
V: Debug,
impl<K, V> Debug for std::collections::hash::map::ValuesMut<'_, K, V>where
V: Debug,
impl<K, V> Debug for hashbrown::map::Iter<'_, K, V>
impl<K, V> Debug for hashbrown::map::IterMut<'_, K, V>
impl<K, V> Debug for hashbrown::map::Keys<'_, K, V>where
K: Debug,
impl<K, V> Debug for hashbrown::map::Values<'_, K, V>where
V: Debug,
impl<K, V> Debug for hashbrown::map::ValuesMut<'_, K, V>where
V: Debug,
impl<K, V> Debug for IndexedEntry<'_, K, V>
impl<K, V> Debug for indexmap::map::core::entry::OccupiedEntry<'_, K, V>
impl<K, V> Debug for indexmap::map::core::entry::VacantEntry<'_, K, V>where
K: Debug,
impl<K, V> Debug for indexmap::map::iter::Drain<'_, K, V>
impl<K, V> Debug for indexmap::map::iter::IntoIter<K, V>
impl<K, V> Debug for indexmap::map::iter::IntoKeys<K, V>where
K: Debug,
impl<K, V> Debug for indexmap::map::iter::IntoValues<K, V>where
V: Debug,
impl<K, V> Debug for indexmap::map::iter::Iter<'_, K, V>
impl<K, V> Debug for IterMut2<'_, K, V>
impl<K, V> Debug for indexmap::map::iter::IterMut<'_, K, V>
impl<K, V> Debug for indexmap::map::iter::Keys<'_, K, V>where
K: Debug,
impl<K, V> Debug for indexmap::map::iter::Values<'_, K, V>where
V: Debug,
impl<K, V> Debug for indexmap::map::iter::ValuesMut<'_, K, V>where
V: Debug,
impl<K, V> Debug for indexmap::map::slice::Slice<K, V>
impl<K, V, A> Debug for alloc::collections::btree::map::entry::Entry<'_, K, V, A>
impl<K, V, A> Debug for alloc::collections::btree::map::entry::OccupiedEntry<'_, K, V, A>
impl<K, V, A> Debug for alloc::collections::btree::map::entry::OccupiedError<'_, K, V, A>
impl<K, V, A> Debug for alloc::collections::btree::map::entry::VacantEntry<'_, K, V, A>
impl<K, V, A> Debug for BTreeMap<K, V, A>
impl<K, V, A> Debug for alloc::collections::btree::map::CursorMut<'_, K, V, A>
impl<K, V, A> Debug for alloc::collections::btree::map::CursorMutKey<'_, K, V, A>
impl<K, V, A> Debug for alloc::collections::btree::map::IntoIter<K, V, A>
impl<K, V, A> Debug for alloc::collections::btree::map::IntoKeys<K, V, A>
impl<K, V, A> Debug for alloc::collections::btree::map::IntoValues<K, V, A>
impl<K, V, A> Debug for hashbrown::map::Drain<'_, K, V, A>
impl<K, V, A> Debug for hashbrown::map::IntoIter<K, V, A>
impl<K, V, A> Debug for hashbrown::map::IntoKeys<K, V, A>
impl<K, V, A> Debug for hashbrown::map::IntoValues<K, V, A>where
V: Debug,
A: Allocator,
impl<K, V, F> Debug for std::collections::hash::map::ExtractIf<'_, K, V, F>
impl<K, V, F, A> Debug for alloc::collections::btree::map::ExtractIf<'_, K, V, F, A>
impl<K, V, S> Debug for RawEntryMut<'_, K, V, S>
impl<K, V, S> Debug for litemap::map::Entry<'_, K, V, S>
impl<K, V, S> Debug for std::collections::hash::map::HashMap<K, V, S>
impl<K, V, S> Debug for RawEntryBuilder<'_, K, V, S>
impl<K, V, S> Debug for RawEntryBuilderMut<'_, K, V, S>
impl<K, V, S> Debug for RawOccupiedEntryMut<'_, K, V, S>
impl<K, V, S> Debug for RawVacantEntryMut<'_, K, V, S>
impl<K, V, S> Debug for IndexMap<K, V, S>
impl<K, V, S> Debug for LiteMap<K, V, S>
impl<K, V, S> Debug for litemap::map::OccupiedEntry<'_, K, V, S>
impl<K, V, S> Debug for litemap::map::VacantEntry<'_, K, V, S>
impl<K, V, S, A> Debug for hashbrown::map::Entry<'_, K, V, S, A>
impl<K, V, S, A> Debug for hashbrown::map::HashMap<K, V, S, A>
impl<K, V, S, A> Debug for hashbrown::map::OccupiedEntry<'_, K, V, S, A>
impl<K, V, S, A> Debug for hashbrown::map::OccupiedError<'_, K, V, S, A>
impl<K, V, S, A> Debug for hashbrown::map::VacantEntry<'_, K, V, S, A>where
K: Debug,
A: Allocator,
impl<L> Debug for ServiceBuilder<L>where
L: Debug,
impl<L, R> Debug for either::Either<L, R>
impl<L, R> Debug for http_body_util::either::Either<L, R>
impl<L, R> Debug for tokio_util::either::Either<L, R>
impl<L, R> Debug for IterEither<L, R>
impl<M> Debug for icu_provider::baked::zerotrie::Data<M>
impl<M> Debug for DataPayload<M>where
M: DynamicDataMarker,
&'a <<M as DynamicDataMarker>::DataStruct as Yokeable<'a>>::Output: for<'a> Debug,
impl<M> Debug for DataResponse<M>where
M: DynamicDataMarker,
&'a <<M as DynamicDataMarker>::DataStruct as Yokeable<'a>>::Output: for<'a> Debug,
impl<M, O> Debug for DataPayloadOr<M, O>where
M: DynamicDataMarker,
&'a <<M as DynamicDataMarker>::DataStruct as Yokeable<'a>>::Output: for<'a> Debug,
O: Debug,
impl<M, P> Debug for DataProviderWithMarker<M, P>
impl<O> Debug for F32<O>where
O: ByteOrder,
impl<O> Debug for F64<O>where
O: ByteOrder,
impl<O> Debug for I16<O>where
O: ByteOrder,
impl<O> Debug for I32<O>where
O: ByteOrder,
impl<O> Debug for I64<O>where
O: ByteOrder,
impl<O> Debug for I128<O>where
O: ByteOrder,
impl<O> Debug for Isize<O>where
O: ByteOrder,
impl<O> Debug for U16<O>where
O: ByteOrder,
impl<O> Debug for U32<O>where
O: ByteOrder,
impl<O> Debug for U64<O>where
O: ByteOrder,
impl<O> Debug for U128<O>where
O: ByteOrder,
impl<O> Debug for Usize<O>where
O: ByteOrder,
impl<Obj, Stream> Debug for RoundResult<Obj, Stream>
impl<Obj, Stream> Debug for StageResult<Obj, Stream>
impl<P> Debug for FollowRedirectLayer<P>where
P: Debug,
impl<Ptr> Debug for Pin<Ptr>where
Ptr: Debug,
impl<R> Debug for std::io::buffered::bufreader::BufReader<R>
impl<R> Debug for std::io::Bytes<R>where
R: Debug,
impl<R> Debug for HttpConnector<R>where
R: Debug,
impl<R> Debug for ReadRng<R>where
R: Debug,
impl<R> Debug for BlockRng64<R>where
R: BlockRngCore + Debug,
impl<R> Debug for BlockRng<R>where
R: BlockRngCore + Debug,
impl<R> Debug for ReaderStream<R>where
R: Debug,
impl<R> Debug for tokio::io::util::buf_reader::BufReader<R>where
R: Debug,
impl<R> Debug for tokio::io::util::lines::Lines<R>where
R: Debug,
impl<R> Debug for tokio::io::util::split::Split<R>where
R: Debug,
impl<R> Debug for tokio::io::util::take::Take<R>where
R: Debug,
impl<R, G, T> Debug for ReentrantMutex<R, G, T>
impl<R, Rsdr> Debug for ReseedingRng<R, Rsdr>
impl<R, T> Debug for lock_api::mutex::Mutex<R, T>
impl<R, T> Debug for lock_api::rwlock::RwLock<R, T>
impl<R, W> Debug for tokio::io::join::Join<R, W>
impl<RW> Debug for BufStream<RW>where
RW: Debug,
impl<Role> Debug for tungstenite::handshake::HandshakeError<Role>where
Role: HandshakeRole,
impl<Role> Debug for MidHandshake<Role>
impl<S> Debug for native_tls::HandshakeError<S>where
S: Debug,
impl<S> Debug for openssl::ssl::error::HandshakeError<S>where
S: Debug,
impl<S> Debug for tokio_tungstenite::stream::MaybeTlsStream<S>where
S: Debug,
impl<S> Debug for tungstenite::stream::MaybeTlsStream<S>
impl<S> Debug for Host<S>where
S: Debug,
impl<S> Debug for futures_util::stream::poll_immediate::PollImmediate<S>where
S: Debug,
impl<S> Debug for SplitStream<S>where
S: Debug,
impl<S> Debug for StreamBody<S>where
S: Debug,
impl<S> Debug for PasswordMasked<'_, RiAbsoluteStr<S>>where
S: Spec,
impl<S> Debug for PasswordMasked<'_, RiStr<S>>where
S: Spec,
impl<S> Debug for PasswordMasked<'_, RiReferenceStr<S>>where
S: Spec,
impl<S> Debug for PasswordMasked<'_, RiRelativeStr<S>>where
S: Spec,
impl<S> Debug for RiAbsoluteStr<S>where
S: Spec,
impl<S> Debug for RiAbsoluteString<S>where
S: Spec,
impl<S> Debug for RiFragmentStr<S>where
S: Spec,
impl<S> Debug for RiFragmentString<S>where
S: Spec,
impl<S> Debug for RiStr<S>where
S: Spec,
impl<S> Debug for RiString<S>where
S: Spec,
impl<S> Debug for RiQueryStr<S>where
S: Spec,
impl<S> Debug for RiQueryString<S>where
S: Spec,
impl<S> Debug for RiReferenceStr<S>where
S: Spec,
impl<S> Debug for RiReferenceString<S>where
S: Spec,
impl<S> Debug for RiRelativeStr<S>where
S: Spec,
impl<S> Debug for RiRelativeString<S>where
S: Spec,
impl<S> Debug for MidHandshakeTlsStream<S>where
S: Debug,
impl<S> Debug for native_tls::TlsStream<S>where
S: Debug,
impl<S> Debug for MidHandshakeSslStream<S>where
S: Debug,
impl<S> Debug for SslStream<S>where
S: Debug,
impl<S> Debug for AllowStd<S>where
S: Debug,
impl<S> Debug for tokio_native_tls::TlsStream<S>where
S: Debug,
impl<S> Debug for Socks4Stream<S>where
S: Debug,
impl<S> Debug for Socks5Stream<S>where
S: Debug,
impl<S> Debug for WebSocketStream<S>where
S: Debug,
impl<S> Debug for CopyToBytes<S>where
S: Debug,
impl<S> Debug for SinkWriter<S>where
S: Debug,
impl<S> Debug for ClientHandshake<S>where
S: Debug,
impl<S> Debug for Ascii<S>where
S: Debug,
impl<S> Debug for UniCase<S>where
S: Debug,
impl<S, B> Debug for StreamReader<S, B>
impl<S, B, P> Debug for tower_http::follow_redirect::ResponseFuture<S, B, P>
impl<S, C> Debug for ServerHandshake<S, C>
impl<S, D> Debug for PasswordReplaced<'_, RiAbsoluteStr<S>, D>
impl<S, D> Debug for PasswordReplaced<'_, RiStr<S>, D>
impl<S, D> Debug for PasswordReplaced<'_, RiReferenceStr<S>, D>
impl<S, D> Debug for PasswordReplaced<'_, RiRelativeStr<S>, D>
impl<S, F> Debug for tower::util::and_then::AndThen<S, F>where
S: Debug,
impl<S, F> Debug for tower::util::map_err::MapErr<S, F>where
S: Debug,
impl<S, F> Debug for MapFuture<S, F>where
S: Debug,
impl<S, F> Debug for MapRequest<S, F>where
S: Debug,
impl<S, F> Debug for MapResponse<S, F>where
S: Debug,
impl<S, F> Debug for MapResult<S, F>where
S: Debug,
impl<S, F> Debug for tower::util::then::Then<S, F>where
S: Debug,
impl<S, Item> Debug for SplitSink<S, Item>
impl<S, P> Debug for FollowRedirect<S, P>
impl<S, Req> Debug for Oneshot<S, Req>
impl<Si1, Si2> Debug for Fanout<Si1, Si2>
impl<Si, F> Debug for SinkMapErr<Si, F>
impl<Si, Item> Debug for Buffer<Si, Item>
impl<Si, Item, E> Debug for SinkErrInto<Si, Item, E>
impl<Si, Item, U, Fut, F> Debug for With<Si, Item, U, Fut, F>
impl<Si, Item, U, St, F> Debug for WithFlatMap<Si, Item, U, St, F>
impl<Si, St> Debug for SendAll<'_, Si, St>
impl<Src, Dst> Debug for AlignmentError<Src, Dst>where
Dst: ?Sized,
impl<Src, Dst> Debug for SizeError<Src, Dst>where
Dst: ?Sized,
impl<Src, Dst> Debug for ValidityError<Src, Dst>where
Dst: TryFromBytes + ?Sized,
impl<St1, St2> Debug for futures_util::stream::select::Select<St1, St2>
impl<St1, St2> Debug for futures_util::stream::stream::chain::Chain<St1, St2>
impl<St1, St2> Debug for futures_util::stream::stream::zip::Zip<St1, St2>
impl<St1, St2, Clos, State> Debug for SelectWithStrategy<St1, St2, Clos, State>
impl<St> Debug for futures_util::stream::select_all::IntoIter<St>
impl<St> Debug for futures_util::stream::select_all::SelectAll<St>where
St: Debug,
impl<St> Debug for BufferUnordered<St>
impl<St> Debug for Buffered<St>
impl<St> Debug for futures_util::stream::stream::catch_unwind::CatchUnwind<St>where
St: Debug,
impl<St> Debug for futures_util::stream::stream::chunks::Chunks<St>
impl<St> Debug for Concat<St>
impl<St> Debug for Count<St>where
St: Debug,
impl<St> Debug for futures_util::stream::stream::cycle::Cycle<St>where
St: Debug,
impl<St> Debug for futures_util::stream::stream::enumerate::Enumerate<St>where
St: Debug,
impl<St> Debug for futures_util::stream::stream::fuse::Fuse<St>where
St: Debug,
impl<St> Debug for StreamFuture<St>where
St: Debug,
impl<St> Debug for Peek<'_, St>
impl<St> Debug for futures_util::stream::stream::peek::PeekMut<'_, St>
impl<St> Debug for futures_util::stream::stream::peek::Peekable<St>
impl<St> Debug for ReadyChunks<St>
impl<St> Debug for futures_util::stream::stream::skip::Skip<St>where
St: Debug,
impl<St> Debug for futures_util::stream::stream::Flatten<St>
impl<St> Debug for futures_util::stream::stream::take::Take<St>where
St: Debug,
impl<St> Debug for futures_util::stream::try_stream::into_stream::IntoStream<St>where
St: Debug,
impl<St> Debug for TryBufferUnordered<St>
impl<St> Debug for TryBuffered<St>
impl<St> Debug for TryChunks<St>
impl<St> Debug for TryConcat<St>
impl<St> Debug for futures_util::stream::try_stream::try_flatten::TryFlatten<St>
impl<St> Debug for TryFlattenUnordered<St>
impl<St> Debug for TryReadyChunks<St>
impl<St, C> Debug for Collect<St, C>
impl<St, C> Debug for TryCollect<St, C>
impl<St, E> Debug for futures_util::stream::try_stream::ErrInto<St, E>
impl<St, F> Debug for futures_util::stream::stream::map::Map<St, F>where
St: Debug,
impl<St, F> Debug for NextIf<'_, St, F>
impl<St, F> Debug for futures_util::stream::stream::Inspect<St, F>
impl<St, F> Debug for futures_util::stream::try_stream::InspectErr<St, F>
impl<St, F> Debug for futures_util::stream::try_stream::InspectOk<St, F>
impl<St, F> Debug for futures_util::stream::try_stream::MapErr<St, F>
impl<St, F> Debug for futures_util::stream::try_stream::MapOk<St, F>
impl<St, FromA, FromB> Debug for Unzip<St, FromA, FromB>
impl<St, Fut> Debug for TakeUntil<St, Fut>
impl<St, Fut, F> Debug for futures_util::stream::stream::all::All<St, Fut, F>
impl<St, Fut, F> Debug for Any<St, Fut, F>
impl<St, Fut, F> Debug for futures_util::stream::stream::filter::Filter<St, Fut, F>
impl<St, Fut, F> Debug for futures_util::stream::stream::filter_map::FilterMap<St, Fut, F>
impl<St, Fut, F> Debug for ForEach<St, Fut, F>
impl<St, Fut, F> Debug for ForEachConcurrent<St, Fut, F>
impl<St, Fut, F> Debug for futures_util::stream::stream::skip_while::SkipWhile<St, Fut, F>
impl<St, Fut, F> Debug for futures_util::stream::stream::take_while::TakeWhile<St, Fut, F>
impl<St, Fut, F> Debug for futures_util::stream::stream::then::Then<St, Fut, F>
impl<St, Fut, F> Debug for futures_util::stream::try_stream::and_then::AndThen<St, Fut, F>
impl<St, Fut, F> Debug for futures_util::stream::try_stream::or_else::OrElse<St, Fut, F>
impl<St, Fut, F> Debug for TryAll<St, Fut, F>
impl<St, Fut, F> Debug for TryAny<St, Fut, F>
impl<St, Fut, F> Debug for TryFilter<St, Fut, F>
impl<St, Fut, F> Debug for TryFilterMap<St, Fut, F>
impl<St, Fut, F> Debug for TryForEach<St, Fut, F>
impl<St, Fut, F> Debug for TryForEachConcurrent<St, Fut, F>
impl<St, Fut, F> Debug for TrySkipWhile<St, Fut, F>
impl<St, Fut, F> Debug for TryTakeWhile<St, Fut, F>
impl<St, Fut, T, F> Debug for Fold<St, Fut, T, F>
impl<St, Fut, T, F> Debug for TryFold<St, Fut, T, F>
impl<St, S, Fut, F> Debug for futures_util::stream::stream::scan::Scan<St, S, Fut, F>
impl<St, Si> Debug for Forward<St, Si>
impl<St, T> Debug for NextIfEq<'_, St, T>
impl<St, U, F> Debug for futures_util::stream::stream::FlatMap<St, U, F>
impl<St, U, F> Debug for FlatMapUnordered<St, U, F>
impl<Store> Debug for ZeroAsciiIgnoreCaseTrie<Store>
impl<Store> Debug for ZeroTrie<Store>where
Store: Debug,
impl<Store> Debug for ZeroTrieExtendedCapacity<Store>
impl<Store> Debug for ZeroTriePerfectHash<Store>
impl<Store> Debug for ZeroTrieSimpleAscii<Store>
impl<Stream> Debug for HandshakeMachine<Stream>where
Stream: Debug,
impl<Stream> Debug for FrameSocket<Stream>where
Stream: Debug,
impl<Stream> Debug for WebSocket<Stream>where
Stream: Debug,
impl<Svc, S> Debug for CallAll<Svc, S>
impl<Svc, S> Debug for CallAllUnordered<Svc, S>
impl<T> Debug for Bound<T>where
T: Debug,
impl<T> Debug for Option<T>where
T: Debug,
impl<T> Debug for llm_tools::ser::core::task::Poll<T>where
T: Debug,
impl<T> Debug for std::sync::mpmc::error::SendTimeoutError<T>
impl<T> Debug for std::sync::mpsc::TrySendError<T>
impl<T> Debug for std::sync::poison::TryLockError<T>
impl<T> Debug for Status<T>where
T: Debug,
impl<T> Debug for MaybeHttpsStream<T>where
T: Debug,
impl<T> Debug for tokio::sync::mpsc::error::SendTimeoutError<T>
impl<T> Debug for tokio::sync::mpsc::error::TrySendError<T>
impl<T> Debug for SetError<T>where
T: Debug,
impl<T> Debug for *const Twhere
T: ?Sized,
impl<T> Debug for *mut Twhere
T: ?Sized,
impl<T> Debug for &T
impl<T> Debug for &mut T
impl<T> Debug for [T]where
T: Debug,
impl<T> Debug for (T₁, T₂, …, Tₙ)
This trait is implemented for tuples up to twelve items long.