Trait nom::lib::std::prelude::v1::v1::Clone1.0.0[][src]

pub trait Clone {
    fn clone(&self) -> Self;

    fn clone_from(&mut self, source: &Self) { ... }
}
Expand description

A common trait for the ability to explicitly duplicate an object.

Differs from Copy in that Copy is implicit and an inexpensive bit-wise copy, while Clone is always explicit and may or may not be expensive. In order to enforce these characteristics, Rust does not allow you to reimplement Copy, but you may reimplement Clone and run arbitrary code.

Since Clone is more general than Copy, you can automatically make anything Copy be Clone as well.

Derivable

This trait can be used with #[derive] if all fields are Clone. The derived implementation of Clone calls clone on each field.

For a generic struct, #[derive] implements Clone conditionally by adding bound Clone on generic parameters.

// `derive` implements Clone for Reading<T> when T is Clone.
#[derive(Clone)]
struct Reading<T> {
    frequency: T,
}

How can I implement Clone?

Types that are Copy should have a trivial implementation of Clone. More formally: if T: Copy, x: T, and y: &T, then let x = y.clone(); is equivalent to let x = *y;. Manual implementations should be careful to uphold this invariant; however, unsafe code must not rely on it to ensure memory safety.

An example is a generic struct holding a function pointer. In this case, the implementation of Clone cannot be derived, but can be implemented as:

struct Generate<T>(fn() -> T);

impl<T> Copy for Generate<T> {}

impl<T> Clone for Generate<T> {
    fn clone(&self) -> Self {
        *self
    }
}

Additional implementors

In addition to the implementors listed below, the following types also implement Clone:

  • Function item types (i.e., the distinct types defined for each function)
  • Function pointer types (e.g., fn() -> i32)
  • Tuple types, if each component also implements Clone (e.g., (), (i32, bool))
  • Closure types, if they capture no value from the environment or if all such captured values implement Clone themselves. Note that variables captured by shared reference always implement Clone (even if the referent doesn’t), while variables captured by mutable reference never implement Clone.

Required methods

Returns a copy of the value.

Examples
let hello = "Hello"; // &str implements Clone

assert_eq!("Hello", hello.clone());

Provided methods

Performs copy-assignment from source.

a.clone_from(&b) is equivalent to a = b.clone() in functionality, but can be overridden to reuse the resources of a to avoid unnecessary allocations.

Implementations on Foreign Types

Clone a sender to send to other threads.

Note, be aware of the lifetime of the sender because all senders (including the original) need to be dropped in order for Receiver::recv to stop blocking.

Shared references can be cloned, but mutable references cannot!

Shared references can be cloned, but mutable references cannot!

Panics

Panics if the value is currently mutably borrowed.

Panics

Panics if other is currently mutably borrowed.

Makes a clone of the Weak pointer that points to the same allocation.

Examples
use std::rc::{Rc, Weak};

let weak_five = Rc::downgrade(&Rc::new(5));

let _ = Weak::clone(&weak_five);

Makes a clone of the Arc pointer.

This creates another pointer to the same allocation, increasing the strong reference count.

Examples
use std::sync::Arc;

let five = Arc::new(5);

let _ = Arc::clone(&five);

Makes a clone of the Weak pointer that points to the same allocation.

Examples
use std::sync::{Arc, Weak};

let weak_five = Arc::downgrade(&Arc::new(5));

let _ = Weak::clone(&weak_five);

Makes a clone of the Rc pointer.

This creates another pointer to the same allocation, increasing the strong reference count.

Examples
use std::rc::Rc;

let five = Rc::new(5);

let _ = Rc::clone(&five);

Implementors

impl Clone for Adler32

impl<S: Clone + StateID> Clone for AhoCorasick<S>

impl Clone for MatchKind

impl Clone for Error

impl Clone for ErrorKind

impl Clone for MatchKind

impl Clone for Config

impl Clone for Builder

impl Clone for Searcher

impl Clone for Match

impl<A> Clone for ArrayString<A> where
    A: Array<Item = u8> + Copy

impl<T: Clone> Clone for CapacityError<T>

impl<A: Array> Clone for IntoIter<A> where
    A::Item: Clone

impl<A: Array> Clone for ArrayVec<A> where
    A::Item: Clone

impl Clone for Stream

impl Clone for Frame

impl Clone for PrintFmt

impl Clone for Backtrace

impl Clone for Box<Utf8Path>

impl<'a> Clone for Utf8Ancestors<'a>

impl<'a> Clone for Utf8Components<'a>

impl<'a> Clone for Iter<'a>

impl<'a> Clone for Utf8Component<'a>

impl<'a> Clone for Utf8Prefix<'a>

impl<'a> Clone for Utf8PrefixComponent<'a>

impl Clone for Dependency

impl Clone for Diagnostic

impl Clone for Artifact

impl Clone for Message

impl Clone for PackageId

impl Clone for Metadata

impl Clone for Resolve

impl Clone for Node

impl Clone for NodeDep

impl Clone for Package

impl Clone for Source

impl Clone for Target

impl Clone for CargoOpt

impl Clone for CfgExpr

impl Clone for Cfg

impl Clone for Platform

impl<'a> Clone for Token<'a>

impl Clone for Func

impl Clone for Expression

impl Clone for Triple

impl Clone for Arch

impl Clone for Vendor

impl Clone for Os

impl Clone for Family

impl Clone for Env

impl Clone for Endian

impl Clone for TargetInfo

impl<T: Clone> Clone for LocalResult<T>

impl Clone for Local

impl Clone for Utc

impl Clone for NaiveDate

impl Clone for IsoWeek

impl Clone for NaiveTime

impl<Tz: Clone + TimeZone> Clone for Date<Tz> where
    Tz::Offset: Clone

impl<Tz: Clone + TimeZone> Clone for DateTime<Tz> where
    Tz::Offset: Clone

impl Clone for Pad

impl Clone for Numeric

impl Clone for Fixed

impl<'a> Clone for Item<'a>

impl Clone for ParseError

impl Clone for Parsed

impl<'a> Clone for StrftimeItems<'a>

impl Clone for Weekday

impl Clone for Month

impl<'help> Clone for App<'help>

impl<'help> Clone for PossibleValue<'help>

impl Clone for ValueHint

impl<'help> Clone for Arg<'help>

impl Clone for ArgGroup<'_>

impl Clone for ErrorKind

impl Clone for ArgMatches

impl<'a> Clone for Values<'a>

impl<'a> Clone for OsValues<'a>

impl<'a> Clone for Indices<'a>

impl Clone for SubCommand

impl Clone for Theme

impl Clone for Config

impl Clone for FileFormat

impl<T: Clone> Clone for File<T> where
    T: FileSource, 

impl Clone for Box<dyn Source + Send + Sync>

impl Clone for Value

impl<T> Clone for Sender<T>

impl<T> Clone for Receiver<T>

impl<T: Clone> Clone for SendError<T>

impl<T: Clone> Clone for TrySendError<T>

impl<T: Clone> Clone for SendTimeoutError<T>

impl Clone for RecvError

impl<'a> Clone for Select<'a>

impl<T> Clone for Stealer<T>

impl<T: Clone> Clone for Steal<T>

impl<T: ?Sized + Pointable> Clone for Atomic<T>

impl<T: Clone> Clone for Owned<T>

impl<T: ?Sized + Pointable> Clone for Shared<'_, T>

impl Clone for Collector

impl<T: Clone> Clone for CachePadded<T>

impl Clone for Unparker

impl Clone for WaitGroup

impl<T: Clone + ?Sized> Clone for DebugIgnore<T>

impl Clone for Expression

impl<L: Clone, R: Clone> Clone for Either<L, R>

impl Clone for WriteStyle

impl<'a> Clone for Chain<'a>

impl Clone for Format

impl Clone for Encoding

impl Clone for Register

impl<T: Clone> Clone for DebugAbbrevOffset<T>

impl<T: Clone> Clone for DebugAddrBase<T>

impl<T: Clone> Clone for DebugAddrIndex<T>

impl<T: Clone> Clone for DebugArangesOffset<T>

impl<T: Clone> Clone for DebugInfoOffset<T>

impl<T: Clone> Clone for DebugLineOffset<T>

impl<T: Clone> Clone for DebugLineStrOffset<T>

impl<T: Clone> Clone for DebugLocListsBase<T>

impl<T: Clone> Clone for DebugLocListsIndex<T>

impl<T: Clone> Clone for DebugMacinfoOffset<T>

impl<T: Clone> Clone for DebugMacroOffset<T>

impl<T: Clone> Clone for RangeListsOffset<T>

impl<T: Clone> Clone for DebugRngListsBase<T>

impl<T: Clone> Clone for DebugRngListsIndex<T>

impl<T: Clone> Clone for DebugStrOffset<T>

impl<T: Clone> Clone for DebugTypesOffset<T>

impl<T: Clone> Clone for DebugFrameOffset<T>

impl<T: Clone> Clone for EhFrameOffset<T>

impl<T: Clone> Clone for UnitSectionOffset<T>

impl Clone for SectionId

impl Clone for DwoId

impl Clone for Arm

impl Clone for AArch64

impl Clone for RiscV

impl Clone for X86

impl Clone for X86_64

impl Clone for DwSect

impl Clone for DwSectV2

impl Clone for DwUt

impl Clone for DwCfa

impl Clone for DwChildren

impl Clone for DwTag

impl Clone for DwAt

impl Clone for DwForm

impl Clone for DwAte

impl Clone for DwLle

impl Clone for DwDs

impl Clone for DwEnd

impl Clone for DwAccess

impl Clone for DwVis

impl Clone for DwLang

impl Clone for DwAddr

impl Clone for DwId

impl Clone for DwCc

impl Clone for DwInl

impl Clone for DwOrd

impl Clone for DwDsc

impl Clone for DwIdx

impl Clone for DwLns

impl Clone for DwLne

impl Clone for DwLnct

impl Clone for DwMacro

impl Clone for DwRle

impl Clone for DwOp

impl Clone for DwEhPe

impl Clone for BigEndian

impl<R: Clone> Clone for DebugAddr<R>

impl<R: Clone + Reader> Clone for DebugFrame<R>

impl<R: Clone + Reader> Clone for EhFrameHdr<R>

impl<R: Clone + Reader> Clone for ParsedEhFrameHdr<R>

impl<'a, R: Clone + Reader> Clone for EhHdrTable<'a, R>

impl<R: Clone + Reader> Clone for EhFrame<R>

impl<'bases, Section: Clone, R: Clone> Clone for CfiEntriesIter<'bases, Section, R> where
    R: Reader,
    Section: UnwindSection<R>, 

impl<'bases, Section: Clone, R: Clone> Clone for CieOrFde<'bases, Section, R> where
    R: Reader,
    Section: UnwindSection<R>, 

impl<R: Clone, Offset: Clone> Clone for CommonInformationEntry<R, Offset> where
    R: Reader<Offset = Offset>,
    Offset: ReaderOffset

impl<'bases, Section: Clone, R: Clone> Clone for PartialFrameDescriptionEntry<'bases, Section, R> where
    R: Reader,
    Section: UnwindSection<R>,
    R::Offset: Clone,
    R::Offset: Clone,
    Section::Offset: Clone

impl<R: Clone, Offset: Clone> Clone for FrameDescriptionEntry<R, Offset> where
    R: Reader<Offset = Offset>,
    Offset: ReaderOffset

impl<R: Clone + Reader, A: Clone + UnwindContextStorage<R>> Clone for UnwindContext<R, A> where
    A::Stack: Clone

impl<'iter, R: Clone> Clone for RegisterRuleIter<'iter, R> where
    R: Reader

impl<R: Reader, S: UnwindContextStorage<R>> Clone for UnwindTableRow<R, S>

impl<R: Clone + Reader> Clone for CfaRule<R>

impl<R: Clone + Reader> Clone for RegisterRule<R>

impl<'a, R: Clone + Reader> Clone for CallFrameInstructionIter<'a, R>

impl Clone for Pointer

impl<'input, Endian: Clone> Clone for EndianSlice<'input, Endian> where
    Endian: Endianity

impl<R: Clone> Clone for DebugAbbrev<R>

impl<R: Clone> Clone for DebugAranges<R>

impl<R: Clone + Reader> Clone for ArangeHeaderIter<R> where
    R::Offset: Clone

impl<R: Clone, Offset: Clone> Clone for ArangeHeader<R, Offset> where
    R: Reader<Offset = Offset>,
    Offset: ReaderOffset

impl<R: Clone + Reader> Clone for ArangeEntryIter<R>

impl<R: Clone> Clone for DebugCuIndex<R>

impl<R: Clone> Clone for DebugTuIndex<R>

impl<R: Clone + Reader> Clone for UnitIndex<R>

impl<'index, R: Clone + Reader> Clone for UnitIndexSectionIterator<'index, R>

impl<R: Clone> Clone for DebugLine<R>

impl<R: Clone, Program: Clone, Offset: Clone> Clone for LineRows<R, Program, Offset> where
    Program: LineProgram<R, Offset>,
    R: Reader<Offset = Offset>,
    Offset: ReaderOffset

impl<R: Clone, Offset: Clone> Clone for LineInstruction<R, Offset> where
    R: Reader<Offset = Offset>,
    Offset: ReaderOffset

impl<R: Clone + Reader> Clone for LineInstructions<R>

impl Clone for LineRow

impl Clone for ColumnType

impl<R: Clone + Reader> Clone for LineSequence<R>

impl<R: Clone, Offset: Clone> Clone for LineProgramHeader<R, Offset> where
    R: Reader<Offset = Offset>,
    Offset: ReaderOffset

impl<R: Clone, Offset: Clone> Clone for IncompleteLineProgram<R, Offset> where
    R: Reader<Offset = Offset>,
    Offset: ReaderOffset

impl<R: Clone, Offset: Clone> Clone for CompleteLineProgram<R, Offset> where
    R: Reader<Offset = Offset>,
    Offset: ReaderOffset

impl<R: Clone, Offset: Clone> Clone for FileEntry<R, Offset> where
    R: Reader<Offset = Offset>,
    Offset: ReaderOffset

impl<R: Clone> Clone for DebugLoc<R>

impl<R: Clone> Clone for DebugLocLists<R>

impl<R: Clone> Clone for LocationLists<R>

impl<R: Clone + Reader> Clone for RawLocListEntry<R> where
    R::Offset: Clone,
    R::Offset: Clone,
    R::Offset: Clone,
    R::Offset: Clone

impl<R: Clone + Reader> Clone for LocationListEntry<R>

impl<T: Clone> Clone for DieReference<T>

impl<R: Clone, Offset: Clone> Clone for Operation<R, Offset> where
    R: Reader<Offset = Offset>,
    Offset: ReaderOffset

impl<R: Clone, Offset: Clone> Clone for Location<R, Offset> where
    R: Reader<Offset = Offset>,
    Offset: ReaderOffset

impl<R: Clone, Offset: Clone> Clone for Piece<R, Offset> where
    R: Reader<Offset = Offset>,
    Offset: ReaderOffset

impl<R: Clone + Reader> Clone for Expression<R>

impl<R: Clone + Reader> Clone for OperationIter<R>

impl<R: Clone + Reader> Clone for PubNamesEntry<R> where
    R::Offset: Clone,
    R::Offset: Clone

impl<R: Clone + Reader> Clone for DebugPubNames<R>

impl<R: Clone + Reader> Clone for PubNamesEntryIter<R>

impl<R: Clone + Reader> Clone for PubTypesEntry<R> where
    R::Offset: Clone,
    R::Offset: Clone

impl<R: Clone + Reader> Clone for DebugPubTypes<R>

impl<R: Clone + Reader> Clone for PubTypesEntryIter<R>

impl<R: Clone> Clone for DebugRanges<R>

impl<R: Clone> Clone for DebugRngLists<R>

impl<R: Clone> Clone for RangeLists<R>

impl<T: Clone> Clone for RawRngListEntry<T>

impl Clone for Range

impl<R: Clone> Clone for DebugStr<R>

impl<R: Clone> Clone for DebugStrOffsets<R>

impl<R: Clone> Clone for DebugLineStr<R>

impl<T: Clone> Clone for UnitOffset<T>

impl<R: Clone> Clone for DebugInfo<R>

impl<R: Clone + Reader> Clone for DebugInfoUnitHeadersIter<R> where
    R::Offset: Clone

impl<Offset: Clone> Clone for UnitType<Offset> where
    Offset: ReaderOffset

impl<R: Clone, Offset: Clone> Clone for UnitHeader<R, Offset> where
    R: Reader<Offset = Offset>,
    Offset: ReaderOffset

impl<'abbrev, 'unit, R: Clone, Offset: Clone> Clone for DebuggingInformationEntry<'abbrev, 'unit, R, Offset> where
    R: Reader<Offset = Offset>,
    Offset: ReaderOffset

impl<R: Clone, Offset: Clone> Clone for AttributeValue<R, Offset> where
    R: Reader<Offset = Offset>,
    Offset: ReaderOffset

impl<R: Clone + Reader> Clone for Attribute<R>

impl<'abbrev, 'entry, 'unit, R: Clone + Reader> Clone for AttrsIter<'abbrev, 'entry, 'unit, R>

impl<'abbrev, 'unit, R: Clone> Clone for EntriesRaw<'abbrev, 'unit, R> where
    R: Reader

impl<'abbrev, 'unit, R: Clone> Clone for EntriesCursor<'abbrev, 'unit, R> where
    R: Reader

impl<'abbrev, 'unit, R: Clone> Clone for EntriesTree<'abbrev, 'unit, R> where
    R: Reader

impl<R: Clone> Clone for DebugTypes<R>

impl<R: Clone + Reader> Clone for DebugTypesUnitHeadersIter<R> where
    R::Offset: Clone

impl Clone for ValueType

impl Clone for Value

impl Clone for Error

impl<'g> Clone for BuildTargetId<'g>

impl<'g> Clone for BuildTargetKind<'g>

impl<'a> Clone for CargoOptions<'a>

impl<'g> Clone for CargoSet<'g>

impl<'g> Clone for FeatureList<'g>

impl<'g, 'a> Clone for DisplayFeatures<'g, 'a>

impl<'g> Clone for FeatureGraph<'g>

impl<'g> Clone for FeatureId<'g>

impl<'g> Clone for FeatureMetadata<'g>

impl<'g> Clone for CrossLink<'g>

impl<F: Clone> Clone for FeatureFilterFn<F>

impl<'g> Clone for FeatureQuery<'g>

impl<'g> Clone for FeatureSet<'g>

impl<'g> Clone for DependsCache<'g>

impl<'g> Clone for Workspace<'g>

impl<'g> Clone for PackageMetadata<'g>

impl<'g> Clone for PackageSource<'g>

impl<'g> Clone for ExternalSource<'g>

impl<'g> Clone for GitReq<'g>

impl<'g> Clone for PackagePublish<'g>

impl<'g> Clone for PackageLink<'g>

impl<'g> Clone for DependencyReq<'g>

impl<'g> Clone for EnabledStatus<'g>

impl<'g> Clone for PackageQuery<'g>

impl<'g> Clone for PackageSet<'g>

impl Clone for PackageId

impl<'g> Clone for PlatformStatus<'g>

impl<'g> Clone for PlatformEval<'g>

impl<T> Clone for Bucket<T>

impl<T: Clone, A: Allocator + Clone> Clone for RawTable<T, A>

impl<T> Clone for RawIter<T>

impl<K: Clone, V: Clone, S: Clone, A: Allocator + Clone> Clone for HashMap<K, V, S, A>

impl<K, V> Clone for Iter<'_, K, V>

impl<K, V> Clone for Keys<'_, K, V>

impl<K, V> Clone for Values<'_, K, V>

impl<T: Clone, S: Clone, A: Allocator + Clone> Clone for HashSet<T, S, A>

impl<K> Clone for Iter<'_, K>

impl<T, S, A: Allocator + Clone> Clone for Intersection<'_, T, S, A>

impl<T, S, A: Allocator + Clone> Clone for Difference<'_, T, S, A>

impl<T, S, A: Allocator + Clone> Clone for SymmetricDifference<'_, T, S, A>

impl<T, S, A: Allocator + Clone> Clone for Union<'_, T, S, A>

impl Clone for Error

impl Clone for Duration

impl Clone for Timestamp

impl Clone for Error

impl<T: Clone> Clone for Serde<T>

impl<'i, W: Clone> Clone for IndentWriter<'i, W>

impl<'i, T: Clone + Display> Clone for Indented<'i, T>

impl<'i, T: Clone + Display> Clone for IndentedSkipIntial<'i, T>

impl<'i, W: Clone> Clone for IndentWriter<'i, W>

impl<K, V, S> Clone for IndexMap<K, V, S> where
    K: Clone,
    V: Clone,
    S: Clone

impl<K, V> Clone for Keys<'_, K, V>

impl<K, V> Clone for Values<'_, K, V>

impl<K, V> Clone for Iter<'_, K, V>

impl<T, S> Clone for IndexSet<T, S> where
    T: Clone,
    S: Clone

impl<T> Clone for Iter<'_, T>

impl<T, S> Clone for Difference<'_, T, S>

impl<T, S> Clone for Intersection<'_, T, S>

impl<T, S1, S2> Clone for SymmetricDifference<'_, T, S1, S2>

impl<T, S> Clone for Union<'_, T, S>

impl<I: Clone> Clone for MultiProduct<I> where
    I: Iterator + Clone,
    I::Item: Clone

impl<I: Clone, J: Clone> Clone for Interleave<I, J>

impl<I: Clone, J: Clone> Clone for InterleaveShortest<I, J> where
    I: Iterator,
    J: Iterator<Item = I::Item>, 

impl<I: Clone> Clone for PutBack<I> where
    I: Iterator,
    I::Item: Clone

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

impl<I: Clone, F: Clone> Clone for Batching<I, F>

impl<I: Clone> Clone for Step<I>

impl<I, J, F> Clone for MergeBy<I, J, F> where
    I: Iterator,
    J: Iterator<Item = I::Item>,
    Peekable<I>: Clone,
    Peekable<J>: Clone,
    F: Clone

impl<I: Clone> Clone for WhileSome<I>

impl<I: Clone, T: Clone> Clone for TupleCombinations<I, T> where
    I: Iterator,
    T: HasCombination<I>,
    T::Combination: Clone

impl<I: Clone, F: Clone> Clone for FilterOk<I, F>

impl<I: Clone, F: Clone> Clone for Positions<I, F>

impl<I: Clone, F: Clone> Clone for Update<I, F>

impl<A: Clone, B: Clone> Clone for EitherOrBoth<A, B>

impl<I, J> Clone for ConsTuples<I, J> where
    I: Clone + Iterator<Item = J>, 

impl<I> Clone for Combinations<I> where
    I: Clone + Iterator,
    I::Item: Clone

impl<I: Clone> Clone for CombinationsWithReplacement<I> where
    I: Iterator,
    I::Item: Clone

impl<I: Clone> Clone for ExactlyOneError<I> where
    I: Iterator,
    I::Item: Clone,
    I::Item: Clone

impl<I, T, E> Clone for FlattenOk<I, T, E> where
    I: Iterator<Item = Result<T, E>> + Clone,
    T: IntoIterator,
    T::IntoIter: Clone

impl<'a, I: Clone, F: Clone> Clone for FormatWith<'a, I, F>

impl<'a, I: Clone> Clone for Format<'a, I>

impl<I: Clone> Clone for GroupingMap<I>

impl<I: Clone, ElemF: Clone> Clone for IntersperseWith<I, ElemF> where
    I: Iterator,
    I::Item: Clone

impl<I, F> Clone for KMergeBy<I, F> where
    I: Iterator + Clone,
    I::Item: Clone,
    F: Clone

impl<I, J, F> Clone for MergeJoinBy<I, J, F> where
    I: Iterator,
    J: Iterator,
    PutBack<Fuse<I>>: Clone,
    PutBack<Fuse<J>>: Clone,
    F: Clone

impl<T: Clone> Clone for MinMaxResult<T>

impl<I: Clone> Clone for MultiPeek<I> where
    I: Iterator,
    I::Item: Clone

impl<I: Clone, F: Clone> Clone for PadUsing<I, F>

impl<I: Clone> Clone for PeekNth<I> where
    I: Iterator,
    I::Item: Clone

impl<I> Clone for Permutations<I> where
    I: Clone + Iterator,
    I::Item: Clone

impl<I> Clone for Powerset<I> where
    I: Clone + Iterator,
    I::Item: Clone

impl<I: Clone + Iterator> Clone for PutBackN<I> where
    I::Item: Clone

impl<I> Clone for RcIter<I>

impl<A: Clone> Clone for RepeatN<A>

impl<F: Clone> Clone for RepeatCall<F>

impl<St: Clone, F: Clone> Clone for Unfold<St, F>

impl<St: Clone, F: Clone> Clone for Iterate<St, F>

impl<T: Clone> Clone for TupleBuffer<T> where
    T: HomogeneousTuple,
    T::Buffer: Clone

impl<I: Clone, T: Clone> Clone for Tuples<I, T> where
    I: Iterator<Item = T::Item>,
    T: HomogeneousTuple,
    T::Buffer: Clone

impl<I: Clone, T: Clone> Clone for TupleWindows<I, T> where
    I: Iterator<Item = T::Item>,
    T: HomogeneousTuple

impl<I: Clone + Iterator, V: Clone, F: Clone> Clone for UniqueBy<I, V, F>

impl<I: Clone + Iterator> Clone for Unique<I> where
    I::Item: Clone

impl<I> Clone for WithPosition<I> where
    I: Clone + Iterator,
    I::Item: Clone

impl<T: Clone> Clone for Position<T>

impl<I: Clone, J: Clone> Clone for ZipEq<I, J>

impl<T: Clone, U: Clone> Clone for ZipLongest<T, U>

impl<T: Clone> Clone for Zip<T>

impl<T: Clone> Clone for FoldWhile<T>

impl Clone for Buffer

impl Clone for ErrorCode

impl Clone for Error

impl Clone for DIR

impl Clone for group

impl Clone for utimbuf

impl Clone for timeval

impl Clone for timespec

impl Clone for rlimit

impl Clone for rusage

impl Clone for ipv6_mreq

impl Clone for hostent

impl Clone for iovec

impl Clone for pollfd

impl Clone for winsize

impl Clone for linger

impl Clone for sigval

impl Clone for itimerval

impl Clone for tms

impl Clone for servent

impl Clone for protoent

impl Clone for FILE

impl Clone for fpos_t

impl Clone for timezone

impl Clone for in_addr

impl Clone for ip_mreq

impl Clone for ip_mreqn

impl Clone for sockaddr

impl Clone for addrinfo

impl Clone for fd_set

impl Clone for tm

impl Clone for Dl_info

impl Clone for lconv

impl Clone for in_pktinfo

impl Clone for ifaddrs

impl Clone for in6_rtmsg

impl Clone for arpreq

impl Clone for arpreq_old

impl Clone for arphdr

impl Clone for mmsghdr

impl Clone for utsname

impl Clone for sigevent

impl Clone for fpos64_t

impl Clone for rlimit64

impl Clone for glob_t

impl Clone for passwd

impl Clone for spwd

impl Clone for dqblk

impl Clone for itimerspec

impl Clone for fsid_t

impl Clone for cpu_set_t

impl Clone for msginfo

impl Clone for sembuf

impl Clone for input_id

impl Clone for input_mask

impl Clone for ff_replay

impl Clone for ff_trigger

impl Clone for ff_effect

impl Clone for Elf32_Ehdr

impl Clone for Elf64_Ehdr

impl Clone for Elf32_Sym

impl Clone for Elf64_Sym

impl Clone for Elf32_Phdr

impl Clone for Elf64_Phdr

impl Clone for Elf32_Shdr

impl Clone for Elf64_Shdr

impl Clone for ucred

impl Clone for mntent

impl Clone for genlmsghdr

impl Clone for regmatch_t

impl Clone for can_filter

impl Clone for sock_fprog

impl Clone for nlmsghdr

impl Clone for nlmsgerr

impl Clone for nlattr

impl Clone for dirent

impl Clone for dirent64

impl Clone for af_alg_iv

impl Clone for mq_attr

impl Clone for statx

impl Clone for aiocb

impl Clone for __timeval

impl Clone for glob64_t

impl Clone for msghdr

impl Clone for cmsghdr

impl Clone for termios

impl Clone for mallinfo

impl Clone for mallinfo2

impl Clone for nl_pktinfo

impl Clone for rtentry

impl Clone for timex

impl Clone for ntptimeval

impl Clone for regex_t

impl Clone for Elf64_Chdr

impl Clone for Elf32_Chdr

impl Clone for seminfo

impl Clone for utmpx

impl Clone for sigset_t

impl Clone for sysinfo

impl Clone for msqid_ds

impl Clone for semid_ds

impl Clone for sigaction

impl Clone for statfs

impl Clone for flock

impl Clone for flock64

impl Clone for siginfo_t

impl Clone for stack_t

impl Clone for stat

impl Clone for stat64

impl Clone for statfs64

impl Clone for statvfs64

impl Clone for user

impl Clone for mcontext_t

impl Clone for ipc_perm

impl Clone for shmid_ds

impl Clone for ucontext_t

impl Clone for statvfs

impl Clone for sem_t

impl Clone for termios2

impl Clone for can_frame

impl Clone for open_how

impl Clone for in6_addr

impl Clone for Level

impl<'a> Clone for Record<'a>

impl<'a> Clone for Metadata<'a>

impl Clone for Prefilter

impl<'n> Clone for Finder<'n>

impl<'n> Clone for FinderRev<'n>

impl Clone for TDEFLFlush

impl Clone for MZFlush

impl Clone for MZStatus

impl Clone for MZError

impl Clone for DataFormat

impl<T: Clone> Clone for Nested<T>

impl<'a, T: Clone + 'a> Clone for Iter<'a, T>

impl<'cfg> Clone for NextestProfile<'cfg>

impl<'cfg> Clone for NextestJunitConfig<'cfg>

impl<'a> Clone for TestEvent<'a>

impl Clone for RunStats

impl Clone for RunIgnored

impl<'g> Clone for RustTestArtifact<'g>

impl<'g> Clone for TestList<'g>

impl<'g> Clone for RustTestSuite<'g>

impl<'a> Clone for TestInstance<'a>

impl Clone for Entry

impl Clone for Type

impl Clone for Errno

impl Clone for AtFlags

impl Clone for OFlag

impl Clone for SealFlag

impl Clone for FdFlag

impl Clone for FlockArg

impl Clone for MsFlags

impl Clone for MntFlags

impl Clone for MQ_OFlag

impl Clone for FdFlag

impl Clone for MqAttr

impl Clone for PollFd

impl Clone for PollFlags

impl Clone for CloneFlags

impl Clone for CpuSet

impl Clone for LioOpcode

impl Clone for LioMode

impl Clone for EpollFlags

impl Clone for EpollOp

impl Clone for EpollEvent

impl Clone for EfdFlags

impl Clone for ProtFlags

impl Clone for MapFlags

impl Clone for MmapAdvise

impl Clone for MsFlags

impl Clone for Persona

impl Clone for Request

impl Clone for Event

impl Clone for Options

impl Clone for QuotaType

impl Clone for QuotaFmt

impl Clone for Dqblk

impl Clone for RebootMode

impl Clone for Resource

impl Clone for FdSet

impl Clone for Signal

impl Clone for SaFlags

impl Clone for SigmaskHow

impl Clone for SigSet

impl Clone for SigHandler

impl Clone for SigAction

impl Clone for SigEvent

impl Clone for SfdFlags

impl Clone for InetAddr

impl Clone for IpAddr

impl Clone for Ipv4Addr

impl Clone for Ipv6Addr

impl Clone for UnixAddr

impl Clone for SockAddr

impl Clone for AlgAddr

impl Clone for LinkAddr

impl Clone for VsockAddr

impl Clone for ReuseAddr

impl Clone for ReusePort

impl Clone for TcpNoDelay

impl Clone for Linger

impl Clone for IpFreebind

impl Clone for Broadcast

impl Clone for OobInline

impl Clone for KeepAlive

impl Clone for TcpMaxSeg

impl Clone for TcpRepair

impl Clone for RcvBuf

impl Clone for SndBuf

impl Clone for SockType

impl Clone for AcceptConn

impl Clone for Mark

impl Clone for PassCred

impl Clone for RxqOvfl

impl Clone for Ipv6V6Only

impl Clone for Ipv4Ttl

impl Clone for Ipv6Ttl

impl<T: Clone> Clone for AlgSetKey<T>

impl Clone for SockType

impl Clone for SockFlag

impl Clone for MsgFlags

impl<'a> Clone for RecvMsg<'a>

impl<'a> Clone for CmsgIterator<'a>

impl<'a> Clone for ControlMessage<'a>

impl Clone for Shutdown

impl Clone for SFlag

impl Clone for Mode

impl Clone for Statfs

impl Clone for FsType

impl Clone for FsFlags

impl Clone for Statvfs

impl Clone for SysInfo

impl Clone for Termios

impl Clone for BaudRate

impl Clone for SetArg

impl Clone for FlushArg

impl Clone for FlowArg

impl Clone for InputFlags

impl Clone for LocalFlags

impl Clone for TimeSpec

impl Clone for TimeVal

impl<T: Clone> Clone for IoVec<T>

impl Clone for UtsName

impl Clone for WaitStatus

impl Clone for InitFlags

impl Clone for Inotify

impl Clone for ClockId

impl Clone for TimerFlags

impl Clone for Expiration

impl Clone for ClockId

impl Clone for UContext

impl Clone for Uid

impl Clone for Gid

impl Clone for Pid

impl Clone for ForkResult

impl Clone for Whence

impl Clone for SysconfVar

impl Clone for ResUid

impl Clone for ResGid

impl Clone for User

impl Clone for Group

impl<A: Clone> Clone for ExtendedGcd<A>

impl Clone for ComdatKind

impl Clone for SymbolKind

impl Clone for FileFlags

impl<Section: Clone> Clone for SymbolFlags<Section>

impl Clone for Endianness

impl Clone for BigEndian

impl<E: Clone + Endian> Clone for U16Bytes<E>

impl<E: Clone + Endian> Clone for U32Bytes<E>

impl<E: Clone + Endian> Clone for U64Bytes<E>

impl<E: Clone + Endian> Clone for I16Bytes<E>

impl<E: Clone + Endian> Clone for I32Bytes<E>

impl<E: Clone + Endian> Clone for I64Bytes<E>

impl<'data> Clone for Bytes<'data>

impl<'data, R: Clone> Clone for StringTable<'data, R> where
    R: ReadRef<'data>, 

impl<'data> Clone for SectionTable<'data>

impl<'data, 'file, R: Clone> Clone for CoffSymbolTable<'data, 'file, R> where
    R: ReadRef<'data>, 

impl<'data, 'file, R: Clone> Clone for CoffSymbol<'data, 'file, R> where
    R: ReadRef<'data>, 

impl<'data, Elf: Clone + FileHeader, R: Clone> Clone for SectionTable<'data, Elf, R> where
    R: ReadRef<'data>,
    Elf::SectionHeader: Clone

impl<'data, Elf: Clone + FileHeader, R: Clone> Clone for SymbolTable<'data, Elf, R> where
    R: ReadRef<'data>,
    Elf::Sym: Clone

impl<'data, 'file, Elf: Clone, R: Clone> Clone for ElfSymbolTable<'data, 'file, Elf, R> where
    'data: 'file,
    Elf: FileHeader,
    R: ReadRef<'data>,
    Elf::Endian: Clone

impl<'data, 'file, Elf: Clone, R: Clone> Clone for ElfSymbol<'data, 'file, Elf, R> where
    'data: 'file,
    Elf: FileHeader,
    R: ReadRef<'data>,
    Elf::Endian: Clone,
    Elf::Sym: Clone

impl<'data> Clone for Version<'data>

impl<'data, Elf: Clone + FileHeader> Clone for VersionTable<'data, Elf> where
    Elf::Endian: Clone

impl<'data, Elf: Clone + FileHeader> Clone for VerdefIterator<'data, Elf> where
    Elf::Endian: Clone

impl<'data, Elf: Clone + FileHeader> Clone for VerdauxIterator<'data, Elf> where
    Elf::Endian: Clone

impl<'data, Elf: Clone + FileHeader> Clone for VerneedIterator<'data, Elf> where
    Elf::Endian: Clone

impl<'data, Elf: Clone + FileHeader> Clone for VernauxIterator<'data, Elf> where
    Elf::Endian: Clone

impl<'data, E: Clone + Endian> Clone for LoadCommandIterator<'data, E>

impl<'data, E: Clone + Endian> Clone for LoadCommandData<'data, E>

impl<'data, E: Clone + Endian> Clone for LoadCommandVariant<'data, E>

impl<'data, Mach: Clone + MachHeader, R: Clone> Clone for SymbolTable<'data, Mach, R> where
    R: ReadRef<'data>,
    Mach::Nlist: Clone

impl<'data, 'file, Mach: Clone, R: Clone> Clone for MachOSymbolTable<'data, 'file, Mach, R> where
    Mach: MachHeader,
    R: ReadRef<'data>, 

impl<'data, 'file, Mach: Clone, R: Clone> Clone for MachOSymbol<'data, 'file, Mach, R> where
    Mach: MachHeader,
    R: ReadRef<'data>,
    Mach::Nlist: Clone

impl<'data> Clone for DataDirectories<'data>

impl<'data> Clone for ExportTarget<'data>

impl<'data> Clone for Export<'data>

impl<'data> Clone for ExportTable<'data>

impl<'data> Clone for ImportTable<'data>

impl<'data> Clone for ImportDescriptorIterator<'data>

impl<'data> Clone for ImportThunkList<'data>

impl<'data> Clone for Import<'data>

impl<'data> Clone for RelocationBlockIterator<'data>

impl<'data> Clone for RelocationIterator<'data>

impl Clone for Relocation

impl<'data> Clone for RichHeaderInfo<'data>

impl Clone for Error

impl Clone for FileKind

impl Clone for ObjectKind

impl<T: Clone + SymbolMapEntry> Clone for SymbolMap<T>

impl<'data> Clone for SymbolMapName<'data>

impl<'data> Clone for ObjectMap<'data>

impl<'data> Clone for ObjectMapEntry<'data>

impl<'data> Clone for Import<'data>

impl<'data> Clone for Export<'data>

impl<'data> Clone for CodeView<'data>

impl<'data> Clone for CompressedData<'data>

impl Clone for Header

impl<E: Clone + Endian> Clone for FileHeader32<E>

impl<E: Clone + Endian> Clone for FileHeader64<E>

impl Clone for Ident

impl<E: Clone + Endian> Clone for SectionHeader32<E>

impl<E: Clone + Endian> Clone for SectionHeader64<E>

impl<E: Clone + Endian> Clone for Sym32<E>

impl<E: Clone + Endian> Clone for Sym64<E>

impl<E: Clone + Endian> Clone for Syminfo32<E>

impl<E: Clone + Endian> Clone for Syminfo64<E>

impl<E: Clone + Endian> Clone for Rel32<E>

impl<E: Clone + Endian> Clone for Rela32<E>

impl<E: Clone + Endian> Clone for Rel64<E>

impl<E: Clone + Endian> Clone for Rela64<E>

impl<E: Clone + Endian> Clone for ProgramHeader32<E>

impl<E: Clone + Endian> Clone for ProgramHeader64<E>

impl<E: Clone + Endian> Clone for Dyn32<E>

impl<E: Clone + Endian> Clone for Dyn64<E>

impl<E: Clone + Endian> Clone for Versym<E>

impl<E: Clone + Endian> Clone for Verdef<E>

impl<E: Clone + Endian> Clone for Verdaux<E>

impl<E: Clone + Endian> Clone for Verneed<E>

impl<E: Clone + Endian> Clone for Vernaux<E>

impl<E: Clone + Endian> Clone for NoteHeader32<E>

impl<E: Clone + Endian> Clone for NoteHeader64<E>

impl<E: Clone + Endian> Clone for HashHeader<E>

impl<E: Clone + Endian> Clone for GnuHashHeader<E>

impl<E: Clone + Endian> Clone for DyldCacheHeader<E>

impl Clone for FatHeader

impl Clone for FatArch32

impl Clone for FatArch64

impl<E: Clone + Endian> Clone for MachHeader32<E>

impl<E: Clone + Endian> Clone for MachHeader64<E>

impl<E: Clone + Endian> Clone for LoadCommand<E>

impl<E: Clone + Endian> Clone for LcStr<E>

impl<E: Clone + Endian> Clone for SegmentCommand32<E>

impl<E: Clone + Endian> Clone for SegmentCommand64<E>

impl<E: Clone + Endian> Clone for Section32<E>

impl<E: Clone + Endian> Clone for Section64<E>

impl<E: Clone + Endian> Clone for Fvmlib<E>

impl<E: Clone + Endian> Clone for FvmlibCommand<E>

impl<E: Clone + Endian> Clone for Dylib<E>

impl<E: Clone + Endian> Clone for DylibCommand<E>

impl<E: Clone + Endian> Clone for SubClientCommand<E>

impl<E: Clone + Endian> Clone for SubLibraryCommand<E>

impl<E: Clone + Endian> Clone for DylinkerCommand<E>

impl<E: Clone + Endian> Clone for ThreadCommand<E>

impl<E: Clone + Endian> Clone for RoutinesCommand32<E>

impl<E: Clone + Endian> Clone for RoutinesCommand64<E>

impl<E: Clone + Endian> Clone for SymtabCommand<E>

impl<E: Clone + Endian> Clone for DysymtabCommand<E>

impl<E: Clone + Endian> Clone for DylibModule32<E>

impl<E: Clone + Endian> Clone for DylibModule64<E>

impl<E: Clone + Endian> Clone for DylibReference<E>

impl<E: Clone + Endian> Clone for TwolevelHint<E>

impl<E: Clone + Endian> Clone for UuidCommand<E>

impl<E: Clone + Endian> Clone for RpathCommand<E>

impl<E: Clone + Endian> Clone for VersionMinCommand<E>

impl<E: Clone + Endian> Clone for BuildToolVersion<E>

impl<E: Clone + Endian> Clone for DyldInfoCommand<E>

impl<E: Clone + Endian> Clone for SymsegCommand<E>

impl<E: Clone + Endian> Clone for IdentCommand<E>

impl<E: Clone + Endian> Clone for FvmfileCommand<E>

impl<E: Clone + Endian> Clone for EntryPointCommand<E>

impl<E: Clone + Endian> Clone for DataInCodeEntry<E>

impl<E: Clone + Endian> Clone for NoteCommand<E>

impl<E: Clone + Endian> Clone for Nlist32<E>

impl<E: Clone + Endian> Clone for Nlist64<E>

impl<E: Clone + Endian> Clone for Relocation<E>

impl Clone for Guid

impl<T: Clone> Clone for OnceCell<T>

impl<T: Clone> Clone for OnceCell<T>

impl<P> Clone for Split<'_, P> where
    P: Pattern

impl Clone for AnsiColors

impl Clone for CssColors

impl Clone for Rgb

impl Clone for DynColors

impl Clone for Effect

impl Clone for Style

impl Clone for Time

impl<N: Clone> Clone for DfsEvent<N>

impl<B: Clone> Clone for Control<B>

impl<N: Clone, VM: Clone> Clone for Dfs<N, VM>

impl<N: Clone, VM: Clone> Clone for DfsPostOrder<N, VM>

impl<N: Clone, VM: Clone> Clone for Bfs<N, VM>

impl<N: Clone, VM: Clone> Clone for Topo<N, VM>

impl<W: Clone, C: Clone> Clone for WalkerIter<W, C>

impl<G: Clone, F: Clone> Clone for NodeFiltered<G, F>

impl<'a, I: Clone, F: Clone + 'a> Clone for NodeFilteredNeighbors<'a, I, F>

impl<'a, I: Clone, F: Clone + 'a> Clone for NodeFilteredNodes<'a, I, F>

impl<'a, G: Clone, I: Clone, F: Clone + 'a> Clone for NodeFilteredEdgeReferences<'a, G, I, F>

impl<'a, G: Clone, I: Clone, F: Clone + 'a> Clone for NodeFilteredEdges<'a, G, I, F>

impl<G: Clone, F: Clone> Clone for EdgeFiltered<G, F>

impl<'a, G: Clone, F: Clone + 'a> Clone for EdgeFilteredNeighbors<'a, G, F> where
    G: IntoEdges,
    G::Edges: Clone

impl<'a, G: Clone, I: Clone, F: Clone + 'a> Clone for EdgeFilteredEdges<'a, G, I, F>

impl<'a, G: Clone, F: Clone + 'a> Clone for EdgeFilteredNeighborsDirected<'a, G, F> where
    G: IntoEdgesDirected,
    G::EdgesDirected: Clone,
    G::NodeId: Clone

impl<G: Clone> Clone for Reversed<G>

impl<I: Clone> Clone for ReversedEdges<I>

impl<N: Clone, E: Clone> Clone for Element<N, E>

impl<I: Clone, F: Clone> Clone for FilterElements<I, F>

impl<Ix: Clone> Clone for EdgeIndex<Ix> where
    Ix: IndexType

impl<Ix: Clone> Clone for OutgoingEdgeIndices<Ix> where
    Ix: IndexType

impl<'a, E: Clone, Ix: Clone> Clone for Neighbors<'a, E, Ix> where
    Ix: IndexType

impl<'a, E, Ix: IndexType> Clone for EdgeReference<'a, E, Ix>

impl<'a, E: Clone, Ix: Clone + IndexType> Clone for EdgeIndices<'a, E, Ix>

impl<Ix: Clone> Clone for NodeIndices<Ix>

impl<E: Clone, Ix: Clone> Clone for List<E, Ix> where
    Ix: IndexType

impl<'a, E, Ix: IndexType> Clone for EdgeReferences<'a, E, Ix>

impl<'a, E: Clone, Ix: Clone> Clone for OutgoingEdgeReferences<'a, E, Ix> where
    Ix: IndexType

impl<NodeId: Clone, EdgeWeight: Clone> Clone for Paths<NodeId, EdgeWeight>

impl<N: Clone> Clone for Dominators<N> where
    N: Copy + Eq + Hash

impl<'a, N: Clone> Clone for DominatorsIter<'a, N> where
    N: 'a + Copy + Eq + Hash

impl<'a, N: Clone> Clone for DominatedByIter<'a, N> where
    N: 'a + Copy + Eq + Hash

impl<N: Clone, VM: Clone> Clone for DfsSpace<N, VM>

impl<G: Clone> Clone for MinSpanningTree<G> where
    G: Data + IntoNodeReferences,
    G::NodeReferences: Clone,
    G::EdgeWeight: Clone,
    G::NodeId: Clone,
    G::NodeId: Clone

impl<N: Clone> Clone for Cycle<N>

impl<N: Clone, E: Clone, Ty, Ix: Clone> Clone for Csr<N, E, Ty, Ix>

impl<'a, E: Clone + 'a, Ty: Clone, Ix: Clone + 'a> Clone for Edges<'a, E, Ty, Ix>

impl<'a, E, Ty, Ix: Copy> Clone for EdgeReference<'a, E, Ty, Ix>

impl<'a, E: Clone + 'a, Ty: Clone, Ix: Clone + 'a> Clone for EdgeReferences<'a, E, Ty, Ix>

impl<'a, Ix: Clone + 'a> Clone for Neighbors<'a, Ix>

impl<Ix: Clone> Clone for NodeIdentifiers<Ix>

impl<'a, N: Clone + 'a, Ix: Clone + IndexType> Clone for NodeReferences<'a, N, Ix>

impl<Ix: Clone> Clone for NodeIndex<Ix>

impl<Ix: Clone> Clone for EdgeIndex<Ix>

impl<E, Ix> Clone for Node<E, Ix> where
    E: Clone,
    Ix: Copy

impl<E, Ix> Clone for Edge<E, Ix> where
    E: Clone,
    Ix: Copy

impl<N, E, Ty, Ix: IndexType> Clone for Graph<N, E, Ty, Ix> where
    N: Clone,
    E: Clone

impl<'a, N: Clone + 'a, Ty: Clone, Ix: Clone + IndexType> Clone for Externals<'a, N, Ty, Ix>

impl<'a, E, Ix> Clone for Neighbors<'a, E, Ix> where
    Ix: IndexType

impl<'a, E: Clone + 'a, Ty: Clone, Ix: Clone + 'a> Clone for EdgesConnecting<'a, E, Ty, Ix> where
    Ty: EdgeType,
    Ix: IndexType

impl<'a, E, Ty, Ix> Clone for Edges<'a, E, Ty, Ix> where
    Ix: IndexType,
    Ty: EdgeType

impl<Ix> Clone for WalkNeighbors<Ix> where
    Ix: IndexType

impl<Ix: Clone> Clone for NodeIndices<Ix>

impl<Ix: Clone> Clone for EdgeIndices<Ix>

impl<'a, E, Ix: IndexType> Clone for EdgeReference<'a, E, Ix>

impl<'a, N: Clone + 'a, Ix: Clone + IndexType> Clone for NodeReferences<'a, N, Ix>

impl<'a, E: Clone + 'a, Ix: Clone + IndexType> Clone for EdgeReferences<'a, E, Ix>

impl<K: Clone> Clone for UnionFind<K>

impl Clone for Direction

impl Clone for Directed

impl Clone for Undirected

impl Clone for Span

impl Clone for TokenTree

impl Clone for Group

impl Clone for Delimiter

impl Clone for Punct

impl Clone for Spacing

impl Clone for Ident

impl Clone for Literal

impl Clone for IntoIter

impl Clone for SpanRange

impl Clone for Report

impl Clone for TestSuite

impl Clone for TestCase

impl Clone for TestRerun

impl Clone for Property

impl Clone for Output

impl<'a> Clone for Attributes<'a>

impl<'a> Clone for Attribute<'a>

impl<'a> Clone for BytesStart<'a>

impl<'a> Clone for BytesDecl<'a>

impl<'a> Clone for BytesEnd<'a>

impl<'a> Clone for BytesText<'a>

impl<'a> Clone for Event<'a>

impl<B: Clone + BufRead> Clone for Reader<B>

impl<W: Clone + Write> Clone for Writer<W>

impl<T: Clone + Send, const N: usize> Clone for IntoIter<T, N>

impl<T: Clone + Ord + Send> Clone for IntoIter<T>

impl<'a, T: Ord + Sync> Clone for Iter<'a, T>

impl<'a, K: Ord + Sync, V: Sync> Clone for Iter<'a, K, V>

impl<'a, T: Ord + Sync + 'a> Clone for Iter<'a, T>

impl<'a, K: Hash + Eq + Sync, V: Sync> Clone for Iter<'a, K, V>

impl<'a, T: Hash + Eq + Sync> Clone for Iter<'a, T>

impl<T: Clone + Send> Clone for IntoIter<T>

impl<'a, T: Sync> Clone for Iter<'a, T>

impl<T: Clone + Send> Clone for IntoIter<T>

impl<'a, T: Sync> Clone for Iter<'a, T>

impl<A: Clone, B: Clone> Clone for Chain<A, B> where
    A: ParallelIterator,
    B: ParallelIterator<Item = A::Item>, 

impl<I: Clone> Clone for Chunks<I> where
    I: IndexedParallelIterator

impl<I: Clone + ParallelIterator> Clone for Cloned<I>

impl<I: Clone + ParallelIterator> Clone for Copied<I>

impl<T: Send> Clone for Empty<T>

impl<I: Clone + ParallelIterator, P: Clone> Clone for Filter<I, P>

impl<I: Clone + ParallelIterator, P: Clone> Clone for FilterMap<I, P>

impl<I: Clone + ParallelIterator, F: Clone> Clone for FlatMap<I, F>

impl<I: Clone + ParallelIterator, F: Clone> Clone for FlatMapIter<I, F>

impl<I: Clone + ParallelIterator> Clone for Flatten<I>

impl<I: Clone, ID: Clone, F: Clone> Clone for Fold<I, ID, F>

impl<I: Clone, U: Clone, F: Clone> Clone for FoldWith<I, U, F>

impl<I: Clone + ParallelIterator, F: Clone> Clone for Inspect<I, F>

impl<I: Clone, J: Clone> Clone for Interleave<I, J> where
    I: IndexedParallelIterator,
    J: IndexedParallelIterator<Item = I::Item>, 

impl<I: Clone, J: Clone> Clone for InterleaveShortest<I, J> where
    I: IndexedParallelIterator,
    J: IndexedParallelIterator<Item = I::Item>, 

impl<I: Clone> Clone for Intersperse<I> where
    I: ParallelIterator,
    I::Item: Clone,
    I::Item: Clone

impl<I: Clone + ParallelIterator, F: Clone> Clone for Map<I, F>

impl<I: Clone + ParallelIterator, T: Clone, F: Clone> Clone for MapWith<I, T, F>

impl<I: Clone + ParallelIterator, INIT: Clone, F: Clone> Clone for MapInit<I, INIT, F>

impl<T: Clone> Clone for MultiZip<T>

impl<T: Clone + Send> Clone for Once<T>

impl<Iter: Clone> Clone for IterBridge<Iter>

impl<T: Clone + Send> Clone for Repeat<T>

impl<T: Clone + Send> Clone for RepeatN<T>

impl<I: Clone> Clone for Skip<I>

impl<D: Clone, S: Clone> Clone for Split<D, S>

impl<I: Clone> Clone for Take<I>

impl<I: Clone, U: Clone, ID: Clone, F: Clone> Clone for TryFold<I, U, ID, F>

impl<I: Clone, U: Clone + Try, F: Clone> Clone for TryFoldWith<I, U, F> where
    U::Ok: Clone

impl<I: Clone + ParallelIterator, F: Clone> Clone for Update<I, F>

impl<T: Clone + Send> Clone for IntoIter<T>

impl<'a, T: Sync> Clone for Iter<'a, T>

impl<T: Clone> Clone for Iter<T>

impl<T: Clone> Clone for Iter<T>

impl<T: Clone + Send> Clone for IntoIter<T>

impl<'a, T: Sync> Clone for Iter<'a, T>

impl<'data, T: Sync> Clone for Iter<'data, T>

impl<'data, T: Sync> Clone for Chunks<'data, T>

impl<'data, T: Sync> Clone for ChunksExact<'data, T>

impl<'data, T: Sync> Clone for Windows<'data, T>

impl<'data, T, P: Clone> Clone for Split<'data, T, P>

impl<'ch> Clone for Chars<'ch>

impl<'ch> Clone for CharIndices<'ch>

impl<'ch> Clone for Bytes<'ch>

impl<'ch> Clone for EncodeUtf16<'ch>

impl<'ch, P: Clone + Pattern> Clone for Split<'ch, P>

impl<'ch, P: Clone + Pattern> Clone for SplitTerminator<'ch, P>

impl<'ch> Clone for Lines<'ch>

impl<'ch> Clone for SplitWhitespace<'ch>

impl<'ch, P: Clone + Pattern> Clone for Matches<'ch, P>

impl<'ch, P: Clone + Pattern> Clone for MatchIndices<'ch, P>

impl<T: Clone + Send> Clone for IntoIter<T>

impl Clone for Error

impl<'t> Clone for Match<'t>

impl Clone for Regex

impl<'r> Clone for CaptureNames<'r>

impl<'c, 't> Clone for SubCaptureMatches<'c, 't>

impl<'t> Clone for NoExpand<'t>

impl Clone for RegexSet

impl Clone for SetMatches

impl<'a> Clone for SetMatchesIter<'a>

impl Clone for RegexSet

impl Clone for SetMatches

impl<'a> Clone for SetMatchesIter<'a>

impl<'t> Clone for Match<'t>

impl Clone for Regex

impl<'r> Clone for CaptureNames<'r>

impl<'c, 't> Clone for SubCaptureMatches<'c, 't>

impl<'t> Clone for NoExpand<'t>

impl Clone for Parser

impl Clone for Error

impl Clone for ErrorKind

impl Clone for Span

impl Clone for Position

impl Clone for Comment

impl Clone for Ast

impl Clone for Concat

impl Clone for Literal

impl Clone for Class

impl Clone for ClassPerl

impl Clone for ClassAscii

impl Clone for ClassSet

impl Clone for Assertion

impl Clone for Repetition

impl Clone for Group

impl Clone for GroupKind

impl Clone for SetFlags

impl Clone for Flags

impl Clone for FlagsItem

impl Clone for Flag

impl Clone for Error

impl Clone for Literals

impl Clone for Literal

impl Clone for Translator

impl Clone for Error

impl Clone for ErrorKind

impl Clone for Hir

impl Clone for HirKind

impl Clone for Literal

impl Clone for Class

impl Clone for ClassBytes

impl Clone for Anchor

impl Clone for Group

impl Clone for GroupKind

impl Clone for Repetition

impl Clone for Parser

impl Clone for Utf8Range

impl Clone for Buffer

impl Clone for Version

impl Clone for VersionReq

impl Clone for Comparator

impl Clone for Op

impl Clone for Prerelease

impl Clone for Error

impl<E> Clone for UnitDeserializer<E>

impl<E> Clone for BoolDeserializer<E>

impl<E> Clone for I8Deserializer<E>

impl<E> Clone for I16Deserializer<E>

impl<E> Clone for I32Deserializer<E>

impl<E> Clone for I64Deserializer<E>

impl<E> Clone for IsizeDeserializer<E>

impl<E> Clone for U8Deserializer<E>

impl<E> Clone for U16Deserializer<E>

impl<E> Clone for U64Deserializer<E>

impl<E> Clone for UsizeDeserializer<E>

impl<E> Clone for F32Deserializer<E>

impl<E> Clone for F64Deserializer<E>

impl<E> Clone for CharDeserializer<E>

impl<E> Clone for I128Deserializer<E>

impl<E> Clone for U128Deserializer<E>

impl<E> Clone for U32Deserializer<E>

impl<'de, E> Clone for StrDeserializer<'de, E>

impl<'de, E> Clone for BorrowedStrDeserializer<'de, E>

impl<E> Clone for StringDeserializer<E>

impl<'a, E> Clone for CowStrDeserializer<'a, E>

impl<'a, E> Clone for BytesDeserializer<'a, E>

impl<'de, E> Clone for BorrowedBytesDeserializer<'de, E>

impl<I: Clone, E: Clone> Clone for SeqDeserializer<I, E>

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

impl Clone for IgnoredAny

impl<'a> Clone for Unexpected<'a>

impl Clone for Category

impl Clone for Map<String, Value>

impl<'a> Clone for PrettyFormatter<'a>

impl Clone for Value

impl Clone for Number

impl<A: Array> Clone for SmallVec<A> where
    A::Item: Clone

impl<A: Array + Clone> Clone for IntoIter<A> where
    A::Item: Clone

impl Clone for ColorLevel

impl Clone for Underscore

impl Clone for Abstract

impl Clone for As

impl Clone for Async

impl Clone for Auto

impl Clone for Await

impl Clone for Become

impl Clone for Box

impl Clone for Break

impl Clone for Const

impl Clone for Continue

impl Clone for Crate

impl Clone for Default

impl Clone for Do

impl Clone for Dyn

impl Clone for Else

impl Clone for Enum

impl Clone for Extern

impl Clone for Final

impl Clone for Fn

impl Clone for For

impl Clone for If

impl Clone for Impl

impl Clone for In

impl Clone for Let

impl Clone for Loop

impl Clone for Macro

impl Clone for Match

impl Clone for Mod

impl Clone for Move

impl Clone for Mut

impl Clone for Override

impl Clone for Priv

impl Clone for Pub

impl Clone for Ref

impl Clone for Return

impl Clone for SelfType

impl Clone for SelfValue

impl Clone for Static

impl Clone for Struct

impl Clone for Super

impl Clone for Trait

impl Clone for Try

impl Clone for Type

impl Clone for Typeof

impl Clone for Union

impl Clone for Unsafe

impl Clone for Unsized

impl Clone for Use

impl Clone for Virtual

impl Clone for Where

impl Clone for While

impl Clone for Yield

impl Clone for Add

impl Clone for AddEq

impl Clone for And

impl Clone for AndAnd

impl Clone for AndEq

impl Clone for At

impl Clone for Bang

impl Clone for Caret

impl Clone for CaretEq

impl Clone for Colon

impl Clone for Colon2

impl Clone for Comma

impl Clone for Div

impl Clone for DivEq

impl Clone for Dollar

impl Clone for Dot

impl Clone for Dot2

impl Clone for Dot3

impl Clone for DotDotEq

impl Clone for Eq

impl Clone for EqEq

impl Clone for Ge

impl Clone for Gt

impl Clone for Le

impl Clone for Lt

impl Clone for MulEq

impl Clone for Ne

impl Clone for Or

impl Clone for OrEq

impl Clone for OrOr

impl Clone for Pound

impl Clone for Question

impl Clone for RArrow

impl Clone for LArrow

impl Clone for Rem

impl Clone for RemEq

impl Clone for FatArrow

impl Clone for Semi

impl Clone for Shl

impl Clone for ShlEq

impl Clone for Shr

impl Clone for ShrEq

impl Clone for Star

impl Clone for Sub

impl Clone for SubEq

impl Clone for Tilde

impl Clone for Brace

impl Clone for Bracket

impl Clone for Paren

impl Clone for Group

impl<'a> Clone for ImplGenerics<'a>

impl<'a> Clone for TypeGenerics<'a>

impl<'a> Clone for Turbofish<'a>

impl Clone for Lifetime

impl Clone for LitStr

impl Clone for LitByteStr

impl Clone for LitByte

impl Clone for LitChar

impl Clone for LitInt

impl Clone for LitFloat

impl<'a> Clone for Cursor<'a>

impl<T, P> Clone for Punctuated<T, P> where
    T: Clone,
    P: Clone

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

impl<T, P> Clone for IntoPairs<T, P> where
    T: Clone,
    P: Clone

impl<T> Clone for IntoIter<T> where
    T: Clone

impl<'a, T> Clone for Iter<'a, T>

impl<T, P> Clone for Pair<T, P> where
    T: Clone,
    P: Clone

impl Clone for Abi

impl Clone for Arm

impl Clone for AttrStyle

impl Clone for Attribute

impl Clone for BareFnArg

impl Clone for BinOp

impl Clone for Binding

impl Clone for Block

impl Clone for ConstParam

impl Clone for Constraint

impl Clone for Data

impl Clone for DataEnum

impl Clone for DataStruct

impl Clone for DataUnion

impl Clone for Expr

impl Clone for ExprArray

impl Clone for ExprAssign

impl Clone for ExprAsync

impl Clone for ExprAwait

impl Clone for ExprBinary

impl Clone for ExprBlock

impl Clone for ExprBox

impl Clone for ExprBreak

impl Clone for ExprCall

impl Clone for ExprCast

impl Clone for ExprField

impl Clone for ExprGroup

impl Clone for ExprIf

impl Clone for ExprIndex

impl Clone for ExprLet

impl Clone for ExprLit

impl Clone for ExprLoop

impl Clone for ExprMacro

impl Clone for ExprMatch

impl Clone for ExprParen

impl Clone for ExprPath

impl Clone for ExprRange

impl Clone for ExprRepeat

impl Clone for ExprReturn

impl Clone for ExprStruct

impl Clone for ExprTry

impl Clone for ExprTuple

impl Clone for ExprType

impl Clone for ExprUnary

impl Clone for ExprUnsafe

impl Clone for ExprWhile

impl Clone for ExprYield

impl Clone for Field

impl Clone for FieldPat

impl Clone for FieldValue

impl Clone for Fields

impl Clone for File

impl Clone for FnArg

impl Clone for Generics

impl Clone for ImplItem

impl Clone for Index

impl Clone for Item

impl Clone for ItemConst

impl Clone for ItemEnum

impl Clone for ItemFn

impl Clone for ItemImpl

impl Clone for ItemMacro

impl Clone for ItemMacro2

impl Clone for ItemMod

impl Clone for ItemStatic

impl Clone for ItemStruct

impl Clone for ItemTrait

impl Clone for ItemType

impl Clone for ItemUnion

impl Clone for ItemUse

impl Clone for Label

impl Clone for Lit

impl Clone for LitBool

impl Clone for Local

impl Clone for Macro

impl Clone for Member

impl Clone for Meta

impl Clone for MetaList

impl Clone for NestedMeta

impl Clone for Pat

impl Clone for PatBox

impl Clone for PatIdent

impl Clone for PatLit

impl Clone for PatMacro

impl Clone for PatOr

impl Clone for PatPath

impl Clone for PatRange

impl Clone for PatRest

impl Clone for PatSlice

impl Clone for PatStruct

impl Clone for PatTuple

impl Clone for PatType

impl Clone for PatWild

impl Clone for Path

impl Clone for QSelf

impl Clone for Receiver

impl Clone for ReturnType

impl Clone for Signature

impl Clone for Stmt

impl Clone for TraitBound

impl Clone for TraitItem

impl Clone for Type

impl Clone for TypeArray

impl Clone for TypeBareFn

impl Clone for TypeGroup

impl Clone for TypeInfer

impl Clone for TypeMacro

impl Clone for TypeNever

impl Clone for TypeParam

impl Clone for TypeParen

impl Clone for TypePath

impl Clone for TypePtr

impl Clone for TypeSlice

impl Clone for TypeTuple

impl Clone for UnOp

impl Clone for UseGlob

impl Clone for UseGroup

impl Clone for UseName

impl Clone for UsePath

impl Clone for UseRename

impl Clone for UseTree

impl Clone for Variadic

impl Clone for Variant

impl Clone for VisCrate

impl Clone for VisPublic

impl Clone for Visibility

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

impl Clone for Error

impl Clone for Size

impl Clone for CDataModel

impl Clone for ParseError

impl Clone for Vendor

impl Clone for Endianness

impl Clone for Triple

impl Clone for Platform

impl Clone for TargetSpec

impl Clone for Triple

impl Clone for ColorSpec

impl Clone for Color

impl Clone for Box<dyn WordSeparator>

impl Clone for AsciiSpace

impl Clone for Box<dyn WordSplitter>

impl Clone for Box<dyn WrapAlgorithm>

impl Clone for FirstFit

impl<'a> Clone for Word<'a>

impl<'a, WrapAlgo: Clone, WordSep: Clone, WordSplit: Clone> Clone for Options<'a, WrapAlgo, WordSep, WordSplit>

impl Clone for Duration

impl Clone for Timespec

impl Clone for SteadyTime

impl Clone for Tm

impl Clone for ParseError

impl Clone for Map<String, Value>

impl Clone for Value

impl Clone for Datetime

impl Clone for Error

impl Clone for Error

impl<T: Clone> Clone for Spanned<T>

impl Clone for XxHash64

impl Clone for XxHash32

impl Clone for Hash64

impl Clone for Hash128

impl Clone for DirEntry