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 AsciiChar
impl Debug for origin_studio::cmp::Ordering
impl Debug for TryReserveErrorKind
impl Debug for Infallible
impl Debug for VarError
impl Debug for origin_studio::io::SeekFrom
impl Debug for IpAddr
impl Debug for Ipv6MulticastScope
impl Debug for SocketAddr
impl Debug for FpCategory
impl Debug for IntErrorKind
impl Debug for GetDisjointMutError
impl Debug for SearchStep
impl Debug for origin_studio::sync::atomic::Ordering
impl Debug for origin_studio::fmt::Alignment
impl Debug for DebugAsHex
impl Debug for Sign
impl Debug for FromBytesWithNulError
impl Debug for c_void
impl Debug for DwarfFileType
impl Debug for Format
impl Debug for SectionId
impl Debug for Vendor
impl Debug for RunTimeEndian
impl Debug for Pointer
impl Debug for gimli::read::Error
impl Debug for IndexSectionId
impl Debug for Value
impl Debug for ValueType
impl Debug for fsconfig_command
impl Debug for membarrier_cmd
impl Debug for membarrier_cmd_flag
impl Debug for procmap_query_flags
impl Debug for rustix::backend::fs::types::Advice
impl Debug for FileType
impl Debug for FlockOperation
impl Debug for rustix::backend::mm::types::Advice
impl Debug for Resource
impl Debug for MembarrierCommand
impl Debug for TimerfdClockId
impl Debug for ClockId
impl Debug for rustix::fs::seek_from::SeekFrom
impl Debug for Direction
impl Debug for DumpableBehavior
impl Debug for EndianMode
impl Debug for FloatingPointMode
impl Debug for MachineCheckMemoryCorruptionKillPolicy
impl Debug for PTracer
impl Debug for SpeculationFeature
impl Debug for TimeStampCounterReadability
impl Debug for TimingMethod
impl Debug for VirtualMemoryMapAddress
impl Debug for FlockOffsetType
impl Debug for FlockType
impl Debug for NanosleepRelativeResult
impl Debug for WakeOp
impl Debug for WakeOpCmp
impl Debug for Capability
impl Debug for CoreSchedulingScope
impl Debug for SecureComputingMode
impl Debug for SysCallUserDispatchFastSwitch
impl Debug for LinkNameSpaceType
impl Debug for Always
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 AllocError
impl Debug for Global
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 origin_studio::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 origin_studio::char::EscapeDebug
impl Debug for origin_studio::char::EscapeDefault
impl Debug for origin_studio::char::EscapeUnicode
impl Debug for ParseCharError
impl Debug for ToLowercase
impl Debug for ToUppercase
impl Debug for TryFromCharError
impl Debug for UnorderedKeyError
impl Debug for TryReserveError
impl Debug for CString
impl Debug for FromVecWithNulError
impl Debug for IntoStringError
impl Debug for NulError
impl Debug for SipHasher
impl Debug for PhantomContravariantLifetime<'_>
impl Debug for PhantomCovariantLifetime<'_>
impl Debug for PhantomInvariantLifetime<'_>
impl Debug for PhantomPinned
impl Debug for Assume
impl Debug for AddrParseError
impl Debug for Ipv4Addr
impl Debug for 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 origin_studio::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 origin_studio::string::Drain<'_>
impl Debug for FromUtf8Error
impl Debug for FromUtf16Error
impl Debug for IntoChars
impl Debug for String
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 Condvar
impl Debug for Duration
impl Debug for TryFromFloatSecsError
impl Debug for ByteString
impl Debug for CStr
impl Debug for FromBytesUntilNulError
impl Debug for BorrowedBuf<'_>
impl Debug for Context<'_>
impl Debug for LocalWaker
impl Debug for RawWaker
impl Debug for RawWakerVTable
impl Debug for Waker
impl Debug for ParseError
impl Debug for AArch64
impl Debug for Arm
impl Debug for LoongArch
impl Debug for MIPS
impl Debug for PowerPc64
impl Debug for RiscV
impl Debug for X86
impl Debug for X86_64
impl Debug for DebugTypeSignature
impl Debug for DwoId
impl Debug for Encoding
impl Debug for LineEncoding
impl Debug for Register
impl Debug for DwAccess
impl Debug for DwAddr
impl Debug for DwAt
impl Debug for DwAte
impl Debug for DwCc
impl Debug for DwCfa
impl Debug for DwChildren
impl Debug for DwDefaulted
impl Debug for DwDs
impl Debug for DwDsc
impl Debug for DwEhPe
impl Debug for DwEnd
impl Debug for DwForm
impl Debug for DwId
impl Debug for DwIdx
impl Debug for DwInl
impl Debug for DwLang
impl Debug for DwLle
impl Debug for DwLnct
impl Debug for DwLne
impl Debug for DwLns
impl Debug for DwMacro
impl Debug for DwOp
impl Debug for DwOrd
impl Debug for DwRle
impl Debug for DwSect
impl Debug for DwSectV2
impl Debug for DwTag
impl Debug for DwUt
impl Debug for DwVirtuality
impl Debug for DwVis
impl Debug for BigEndian
impl Debug for LittleEndian
impl Debug for ArangeEntry
impl Debug for Augmentation
impl Debug for BaseAddresses
impl Debug for SectionBaseAddresses
impl Debug for UnitIndexSection
impl Debug for ReaderOffsetId
impl Debug for gimli::read::rnglists::Range
impl Debug for StoreOnHeap
impl Debug for __kernel_fd_set
impl Debug for __kernel_fsid_t
impl Debug for __kernel_itimerspec
impl Debug for __kernel_old_itimerval
impl Debug for __kernel_old_timespec
impl Debug for __kernel_old_timeval
impl Debug for __kernel_sock_timeval
impl Debug for __kernel_timespec
impl Debug for __old_kernel_stat
impl Debug for __sifields__bindgen_ty_1
impl Debug for __sifields__bindgen_ty_4
impl Debug for __sifields__bindgen_ty_5__bindgen_ty_1__bindgen_ty_1
impl Debug for __sifields__bindgen_ty_5__bindgen_ty_1__bindgen_ty_2
impl Debug for __sifields__bindgen_ty_5__bindgen_ty_1__bindgen_ty_3
impl Debug for __sifields__bindgen_ty_6
impl Debug for __sifields__bindgen_ty_7
impl Debug for __user_cap_data_struct
impl Debug for __user_cap_header_struct
impl Debug for cachestat
impl Debug for cachestat_range
impl Debug for clone_args
impl Debug for compat_statfs64
impl Debug for dmabuf_cmsg
impl Debug for dmabuf_token
impl Debug for epoll_event
impl Debug for epoll_params
impl Debug for f_owner_ex
impl Debug for file_clone_range
impl Debug for file_dedupe_range
impl Debug for file_dedupe_range_info
impl Debug for files_stat_struct
impl Debug for flock64
impl Debug for flock
impl Debug for fs_sysfs_path
impl Debug for fscrypt_key
impl Debug for fscrypt_policy_v1
impl Debug for fscrypt_policy_v2
impl Debug for fscrypt_provisioning_key_payload
impl Debug for fstrim_range
impl Debug for fsuuid2
impl Debug for fsxattr
impl Debug for futex_waitv
impl Debug for inodes_stat_t
impl Debug for inotify_event
impl Debug for iovec
impl Debug for itimerspec
impl Debug for itimerval
impl Debug for kernel_sigaction
impl Debug for kernel_sigset_t
impl Debug for ktermios
impl Debug for linux_dirent64
impl Debug for mnt_id_req
impl Debug for mount_attr
impl Debug for open_how
impl Debug for page_region
impl Debug for pm_scan_arg
impl Debug for pollfd
impl Debug for procmap_query
impl Debug for rand_pool_info
impl Debug for rlimit64
impl Debug for rlimit
impl Debug for robust_list
impl Debug for robust_list_head
impl Debug for rusage
impl Debug for sigaltstack
impl Debug for sigevent__bindgen_ty_1__bindgen_ty_1
impl Debug for stat64
impl Debug for stat
impl Debug for statfs64
impl Debug for statfs
impl Debug for statmount
impl Debug for statx
impl Debug for statx_timestamp
impl Debug for termio
impl Debug for termios2
impl Debug for termios
impl Debug for timespec
impl Debug for timeval
impl Debug for timezone
impl Debug for uffd_msg__bindgen_ty_1__bindgen_ty_2
impl Debug for uffd_msg__bindgen_ty_1__bindgen_ty_3
impl Debug for uffd_msg__bindgen_ty_1__bindgen_ty_4
impl Debug for uffd_msg__bindgen_ty_1__bindgen_ty_5
impl Debug for uffdio_api
impl Debug for uffdio_continue
impl Debug for uffdio_copy
impl Debug for uffdio_move
impl Debug for uffdio_poison
impl Debug for uffdio_range
impl Debug for uffdio_register
impl Debug for uffdio_writeprotect
impl Debug for uffdio_zeropage
impl Debug for user_desc
impl Debug for vfs_cap_data
impl Debug for vfs_cap_data__bindgen_ty_1
impl Debug for vfs_ns_cap_data
impl Debug for vfs_ns_cap_data__bindgen_ty_1
impl Debug for vgetrandom_opaque_params
impl Debug for winsize
impl Debug for xattr_args
impl Debug for prctl_mm_map
impl Debug for WaitTimeoutResult
impl Debug for rustix_futex_sync::once::Once
impl Debug for OnceState
impl Debug for Dir
impl Debug for DirEntry
impl Debug for CreateFlags
impl Debug for ReadFlags
impl Debug for WatchFlags
impl Debug for Access
impl Debug for AtFlags
impl Debug for FallocateFlags
impl Debug for Fsid
impl Debug for MemfdFlags
impl Debug for Mode
impl Debug for OFlags
impl Debug for RenameFlags
impl Debug for ResolveFlags
impl Debug for SealFlags
impl Debug for Stat
impl Debug for StatFs
impl Debug for StatVfsMountFlags
impl Debug for Errno
impl Debug for DupFlags
impl Debug for FdFlags
impl Debug for ReadWriteFlags
impl Debug for MapFlags
impl Debug for MlockAllFlags
impl Debug for MlockFlags
impl Debug for MprotectFlags
impl Debug for MremapFlags
impl Debug for MsyncFlags
impl Debug for ProtFlags
impl Debug for UserfaultfdFlags
impl Debug for Flags
impl Debug for WaitFlags
impl Debug for TimerfdFlags
impl Debug for TimerfdTimerFlags
impl Debug for Timestamps
impl Debug for IFlags
impl Debug for Statx
impl Debug for StatxAttributes
impl Debug for StatxFlags
impl Debug for StatxTimestamp
impl Debug for XattrFlags
impl Debug for BorrowedFd<'_>
impl Debug for OwnedFd
impl Debug for DecInt
impl Debug for Pid
impl Debug for PidfdFlags
impl Debug for PidfdGetfdFlags
impl Debug for FloatingPointEmulationControl
impl Debug for FloatingPointExceptionMode
impl Debug for PrctlMmMap
impl Debug for SpeculationFeatureControl
impl Debug for SpeculationFeatureState
impl Debug for UnalignedAccessControl
impl Debug for Rlimit
impl Debug for Flock
impl Debug for WaitIdOptions
impl Debug for WaitIdStatus
impl Debug for WaitOptions
impl Debug for WaitStatus
impl Debug for KernelSigaction
impl Debug for KernelSigactionFlags
impl Debug for Signal
impl Debug for Wait
impl Debug for WaitPtr
impl Debug for WaitvFlags
impl Debug for Cpuid
impl Debug for CapabilityFlags
impl Debug for CapabilitySets
impl Debug for MembarrierQuery
impl Debug for CapabilitiesSecureBits
impl Debug for SVEVectorLengthConfig
impl Debug for TaggedAddressMode
impl Debug for CpuSet
impl Debug for ThreadNameSpaceType
impl Debug for Itimerspec
impl Debug for Timespec
impl Debug for Gid
impl Debug for Uid
impl Debug for Arguments<'_>
impl Debug for origin_studio::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<'a> Debug for Utf8Pattern<'a>
impl<'a> Debug for DynamicClockId<'a>
impl<'a> Debug for WaitId<'a>
impl<'a> Debug for Request<'a>
impl<'a> Debug for Source<'a>
impl<'a> Debug for origin_studio::panic::Location<'a>
impl<'a> Debug for PanicInfo<'a>
impl<'a> Debug for EscapeAscii<'a>
impl<'a> Debug for CharSearcher<'a>
impl<'a> Debug for origin_studio::str::Bytes<'a>
impl<'a> Debug for CharIndices<'a>
impl<'a> Debug for origin_studio::str::EscapeDebug<'a>
impl<'a> Debug for origin_studio::str::EscapeDefault<'a>
impl<'a> Debug for origin_studio::str::EscapeUnicode<'a>
impl<'a> Debug for 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 core::ffi::c_str::Bytes<'a>
impl<'a> Debug for BorrowedCursor<'a>
impl<'a> Debug for ContextBuilder<'a>
impl<'a> Debug for Event<'a>
impl<'a> Debug for RawDirEntry<'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, 'bases, R> Debug for EhHdrTableIter<'a, 'bases, R>
impl<'a, 'ctx, R, S> Debug for UnwindTable<'a, 'ctx, R, S>
impl<'a, 'f> Debug for VaList<'a, 'f>where
'f: 'a,
impl<'a, A> Debug for origin_studio::option::Iter<'a, A>where
A: Debug + 'a,
impl<'a, A> Debug for origin_studio::option::IterMut<'a, A>where
A: Debug + 'a,
impl<'a, I> Debug for ByRefSized<'a, I>where
I: Debug,
impl<'a, I, A> Debug for Splice<'a, I, A>
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 origin_studio::str::RSplit<'a, P>
impl<'a, P> Debug for origin_studio::str::RSplitN<'a, P>
impl<'a, P> Debug for RSplitTerminator<'a, P>
impl<'a, P> Debug for origin_studio::str::Split<'a, P>
impl<'a, P> Debug for origin_studio::str::SplitInclusive<'a, P>
impl<'a, P> Debug for origin_studio::str::SplitN<'a, P>
impl<'a, P> Debug for SplitTerminator<'a, P>
impl<'a, R> Debug for CallFrameInstructionIter<'a, R>
impl<'a, R> Debug for EhHdrTable<'a, R>
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 MappedMutexGuard<'a, R, T>
impl<'a, R, T> Debug for MutexGuard<'a, R, T>
impl<'a, R, T> Debug for MappedRwLockReadGuard<'a, R, T>
impl<'a, R, T> Debug for MappedRwLockWriteGuard<'a, R, T>
impl<'a, R, T> Debug for RwLockReadGuard<'a, R, T>
impl<'a, R, T> Debug for RwLockUpgradableReadGuard<'a, R, T>
impl<'a, R, T> Debug for RwLockWriteGuard<'a, R, T>
impl<'a, T> Debug for origin_studio::collections::btree_set::Range<'a, T>where
T: Debug + 'a,
impl<'a, T> Debug for origin_studio::result::Iter<'a, T>where
T: Debug + 'a,
impl<'a, T> Debug for origin_studio::result::IterMut<'a, T>where
T: Debug + 'a,
impl<'a, T> Debug for 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, A> Debug for origin_studio::collections::binary_heap::Drain<'a, T, A>
impl<'a, T, A> Debug for DrainSorted<'a, T, A>
impl<'a, T, F, A> Debug for origin_studio::vec::ExtractIf<'a, T, F, A>
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, const N: usize> Debug for origin_studio::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, const N: usize> Debug for CharArraySearcher<'a, N>
impl<'bases, Section, R> Debug for CieOrFde<'bases, Section, R>
impl<'bases, Section, R> Debug for CfiEntriesIter<'bases, Section, R>
impl<'bases, Section, R> Debug for PartialFrameDescriptionEntry<'bases, Section, R>where
Section: Debug + UnwindSection<R>,
R: Debug + Reader,
<R as Reader>::Offset: Debug,
<Section as UnwindSection<R>>::Offset: Debug,
impl<'f> Debug for VaListImpl<'f>
impl<'index, R> Debug for UnitIndexSectionIterator<'index, R>
impl<'input, Endian> Debug for EndianSlice<'input, Endian>where
Endian: Endianity,
impl<'iter, T> Debug for RegisterRuleIter<'iter, T>where
T: Debug + ReaderOffset,
impl<A> Debug for Repeat<A>where
A: Debug,
impl<A> Debug for RepeatN<A>where
A: Debug,
impl<A> Debug for origin_studio::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, B> Debug for Chain<A, B>
impl<A, B> Debug for Zip<A, B>
impl<B> Debug for Cow<'_, B>
impl<B> Debug for Flag<B>where
B: Debug,
impl<B, C> Debug for ControlFlow<B, C>
impl<Dyn> Debug for DynMetadata<Dyn>where
Dyn: ?Sized,
impl<F> Debug for PollFn<F>
impl<F> Debug for origin_studio::iter::FromFn<F>
impl<F> Debug for OnceWith<F>
impl<F> Debug for RepeatWith<F>
impl<F> Debug for CharPredicateSearcher<'_, F>
impl<F> Debug for origin_studio::fmt::FromFn<F>
impl<F> Debug for Fwhere
F: FnPtr,
impl<G> Debug for FromCoroutine<G>
impl<H> Debug for BuildHasherDefault<H>
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 Cycle<I>where
I: Debug,
impl<I> Debug for Enumerate<I>where
I: Debug,
impl<I> Debug for Fuse<I>where
I: Debug,
impl<I> Debug for Intersperse<I>
impl<I> Debug for Peekable<I>
impl<I> Debug for Skip<I>where
I: Debug,
impl<I> Debug for StepBy<I>where
I: Debug,
impl<I> Debug for Take<I>where
I: Debug,
impl<I, F> Debug for FilterMap<I, F>where
I: Debug,
impl<I, F> Debug for Inspect<I, F>where
I: Debug,
impl<I, F> Debug for 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, P> Debug for Filter<I, P>where
I: Debug,
impl<I, P> Debug for MapWhile<I, P>where
I: Debug,
impl<I, P> Debug for SkipWhile<I, P>where
I: Debug,
impl<I, P> Debug for TakeWhile<I, P>where
I: Debug,
impl<I, St, F> Debug for Scan<I, St, F>
impl<I, U> Debug for Flatten<I>
impl<I, U, F> Debug for FlatMap<I, U, F>
impl<I, const N: usize> Debug for origin_studio::iter::ArrayChunks<I, N>
impl<Idx> Debug for origin_studio::ops::Range<Idx>where
Idx: Debug,
impl<Idx> Debug for origin_studio::ops::RangeFrom<Idx>where
Idx: Debug,
impl<Idx> Debug for origin_studio::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 origin_studio::range::Range<Idx>where
Idx: Debug,
impl<Idx> Debug for origin_studio::range::RangeFrom<Idx>where
Idx: Debug,
impl<Idx> Debug for origin_studio::range::RangeInclusive<Idx>where
Idx: Debug,
impl<K> Debug for origin_studio::collections::btree_set::Cursor<'_, K>where
K: Debug,
impl<K, A> Debug for origin_studio::collections::btree_set::CursorMut<'_, K, A>where
K: Debug,
impl<K, A> Debug for origin_studio::collections::btree_set::CursorMutKey<'_, K, A>where
K: Debug,
impl<K, V> Debug for origin_studio::collections::btree_map::Cursor<'_, K, V>
impl<K, V> Debug for origin_studio::collections::btree_map::Iter<'_, K, V>
impl<K, V> Debug for origin_studio::collections::btree_map::IterMut<'_, K, V>
impl<K, V> Debug for Keys<'_, K, V>where
K: Debug,
impl<K, V> Debug for origin_studio::collections::btree_map::Range<'_, K, V>
impl<K, V> Debug for RangeMut<'_, K, V>
impl<K, V> Debug for Values<'_, K, V>where
V: Debug,
impl<K, V> Debug for ValuesMut<'_, K, V>where
V: Debug,
impl<K, V, A> Debug for origin_studio::collections::btree_map::Entry<'_, K, V, A>
impl<K, V, A> Debug for origin_studio::collections::btree_map::CursorMut<'_, K, V, A>
impl<K, V, A> Debug for origin_studio::collections::btree_map::CursorMutKey<'_, K, V, A>
impl<K, V, A> Debug for origin_studio::collections::btree_map::IntoIter<K, V, A>
impl<K, V, A> Debug for IntoKeys<K, V, A>
impl<K, V, A> Debug for IntoValues<K, V, A>
impl<K, V, A> Debug for origin_studio::collections::btree_map::OccupiedEntry<'_, K, V, A>
impl<K, V, A> Debug for OccupiedError<'_, K, V, A>
impl<K, V, A> Debug for origin_studio::collections::btree_map::VacantEntry<'_, K, V, A>
impl<K, V, A> Debug for BTreeMap<K, V, A>
impl<K, V, F> Debug for origin_studio::collections::btree_map::ExtractIf<'_, K, V, F>
impl<Ptr> Debug for Pin<Ptr>where
Ptr: Debug,
impl<R> Debug for RawLocListEntry<R>
impl<R> Debug for EvaluationResult<R>
impl<R> Debug for DebugAddr<R>where
R: Debug,
impl<R> Debug for ArangeEntryIter<R>
impl<R> Debug for ArangeHeaderIter<R>
impl<R> Debug for DebugAranges<R>where
R: Debug,
impl<R> Debug for DebugFrame<R>
impl<R> Debug for EhFrame<R>
impl<R> Debug for EhFrameHdr<R>
impl<R> Debug for ParsedEhFrameHdr<R>
impl<R> Debug for DebugCuIndex<R>where
R: Debug,
impl<R> Debug for DebugTuIndex<R>where
R: Debug,
impl<R> Debug for UnitIndex<R>
impl<R> Debug for DebugLoc<R>where
R: Debug,
impl<R> Debug for DebugLocLists<R>where
R: Debug,
impl<R> Debug for LocListIter<R>
impl<R> Debug for LocationListEntry<R>
impl<R> Debug for LocationLists<R>where
R: Debug,
impl<R> Debug for RawLocListIter<R>
impl<R> Debug for Expression<R>
impl<R> Debug for OperationIter<R>
impl<R> Debug for DebugRanges<R>where
R: Debug,
impl<R> Debug for DebugRngLists<R>where
R: Debug,
impl<R> Debug for RangeLists<R>where
R: Debug,
impl<R> Debug for RawRngListIter<R>
impl<R> Debug for RngListIter<R>
impl<R> Debug for DebugLineStr<R>where
R: Debug,
impl<R> Debug for DebugStr<R>where
R: Debug,
impl<R> Debug for DebugStrOffsets<R>where
R: Debug,
impl<R, G, T> Debug for ReentrantMutex<R, G, T>
impl<R, Offset> Debug for gimli::read::op::Location<R, Offset>
impl<R, Offset> Debug for Operation<R, Offset>
impl<R, Offset> Debug for ArangeHeader<R, Offset>
impl<R, Offset> Debug for CommonInformationEntry<R, Offset>
impl<R, Offset> Debug for FrameDescriptionEntry<R, Offset>
impl<R, Offset> Debug for Piece<R, Offset>
impl<R, S> Debug for Evaluation<R, S>where
R: Debug + Reader,
S: Debug + EvaluationStorage<R>,
<S as EvaluationStorage<R>>::Stack: Debug,
<S as EvaluationStorage<R>>::ExpressionStack: Debug,
<S as EvaluationStorage<R>>::Result: Debug,
impl<R, T> Debug for RelocateReader<R, T>
impl<R, T> Debug for Mutex<R, T>
impl<R, T> Debug for RwLock<R, T>
impl<Storage> Debug for __BindgenBitfieldUnit<Storage>where
Storage: Debug,
impl<T> Debug for Bound<T>where
T: Debug,
impl<T> Debug for Option<T>where
T: Debug,
impl<T> Debug for Poll<T>where
T: Debug,
impl<T> Debug for UnitSectionOffset<T>where
T: Debug,
impl<T> Debug for CallFrameInstruction<T>where
T: Debug + ReaderOffset,
impl<T> Debug for CfaRule<T>where
T: Debug + ReaderOffset,
impl<T> Debug for RegisterRule<T>where
T: Debug + ReaderOffset,
impl<T> Debug for DieReference<T>where
T: Debug,
impl<T> Debug for RawRngListEntry<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.