(function() {var implementors = {}; implementors["backtrace"] = [{text:"impl Debug for Frame",synthetic:false,types:["backtrace::backtrace::Frame"]},{text:"impl Debug for Symbol",synthetic:false,types:["backtrace::symbolize::Symbol"]},{text:"impl<'a> Debug for SymbolName<'a>",synthetic:false,types:["backtrace::symbolize::SymbolName"]},{text:"impl Debug for Backtrace",synthetic:false,types:["backtrace::capture::Backtrace"]},]; implementors["crossbeam"] = [{text:"impl<T: Debug> Debug for Atomic<T>",synthetic:false,types:["crossbeam::epoch::atomic::Atomic"]},{text:"impl Debug for Guard",synthetic:false,types:["crossbeam::epoch::guard::Guard"]},{text:"impl<T: Debug> Debug for Owned<T>",synthetic:false,types:["crossbeam::epoch::Owned"]},{text:"impl<'a, T: Debug + 'a> Debug for Shared<'a, T>",synthetic:false,types:["crossbeam::epoch::Shared"]},{text:"impl<T: Debug> Debug for AtomicOption<T>",synthetic:false,types:["crossbeam::sync::atomic_option::AtomicOption"]},{text:"impl<T: Debug> Debug for MsQueue<T>",synthetic:false,types:["crossbeam::sync::ms_queue::MsQueue"]},{text:"impl<T: Debug> Debug for TreiberStack<T>",synthetic:false,types:["crossbeam::sync::treiber_stack::TreiberStack"]},{text:"impl<T: Debug> Debug for SegQueue<T>",synthetic:false,types:["crossbeam::sync::seg_queue::SegQueue"]},{text:"impl<T: Debug> Debug for Worker<T>",synthetic:false,types:["crossbeam::sync::chase_lev::Worker"]},{text:"impl<T: Debug> Debug for Stealer<T>",synthetic:false,types:["crossbeam::sync::chase_lev::Stealer"]},{text:"impl<T: Debug> Debug for Steal<T>",synthetic:false,types:["crossbeam::sync::chase_lev::Steal"]},{text:"impl<T: Debug> Debug for ArcCell<T>",synthetic:false,types:["crossbeam::sync::arc_cell::ArcCell"]},{text:"impl<'a> Debug for Scope<'a>",synthetic:false,types:["crossbeam::scoped::Scope"]},{text:"impl<T> Debug for ScopedJoinHandle<T>",synthetic:false,types:["crossbeam::scoped::ScopedJoinHandle"]},{text:"impl<T> Debug for CachePadded<T>",synthetic:false,types:["crossbeam::cache_padded::CachePadded"]},]; implementors["failure"] = [{text:"impl Debug for Backtrace",synthetic:false,types:["failure::backtrace::Backtrace"]},{text:"impl<E: Debug> Debug for Compat<E>",synthetic:false,types:["failure::compat::Compat"]},{text:"impl<D: Display + Send + Sync + 'static> Debug for Context<D>",synthetic:false,types:["failure::context::Context"]},{text:"impl<T> Debug for SyncFailure<T> where
    T: Debug
",synthetic:false,types:["failure::sync_failure::SyncFailure"]},{text:"impl Debug for Error",synthetic:false,types:["failure::error::Error"]},]; implementors["futures"] = [{text:"impl<T: Debug> Debug for Async<T>",synthetic:false,types:["futures::poll::Async"]},{text:"impl<T: Debug> Debug for AsyncSink<T>",synthetic:false,types:["futures::poll::AsyncSink"]},{text:"impl<T: Debug, E: Debug> Debug for Empty<T, E>",synthetic:false,types:["futures::future::empty::Empty"]},{text:"impl<F: Debug, R: Debug + IntoFuture> Debug for Lazy<F, R> where
    R::Future: Debug
",synthetic:false,types:["futures::future::lazy::Lazy"]},{text:"impl<F: Debug> Debug for PollFn<F>",synthetic:false,types:["futures::future::poll_fn::PollFn"]},{text:"impl<T: Debug, E: Debug> Debug for FutureResult<T, E>",synthetic:false,types:["futures::future::result_::FutureResult"]},{text:"impl<T: Debug, S: Debug> Debug for Loop<T, S>",synthetic:false,types:["futures::future::loop_fn::Loop"]},{text:"impl<A: Debug, F: Debug> Debug for LoopFn<A, F> where
    A: IntoFuture,
    A::Future: Debug
",synthetic:false,types:["futures::future::loop_fn::LoopFn"]},{text:"impl<A: Debug, B: Debug, F: Debug> Debug for AndThen<A, B, F> where
    A: Future,
    B: IntoFuture,
    B::Future: Debug
",synthetic:false,types:["futures::future::and_then::AndThen"]},{text:"impl<A> Debug for Flatten<A> where
    A: Future + Debug,
    A::Item: IntoFuture,
    <<A as IntoFuture>::Item as IntoFuture>::Future: Debug
",synthetic:false,types:["futures::future::flatten::Flatten"]},{text:"impl<F> Debug for FlattenStream<F> where
    F: Future + Debug,
    <F as Future>::Item: Stream<Error = F::Error> + Debug
",synthetic:false,types:["futures::future::flatten_stream::FlattenStream"]},{text:"impl<A: Debug + Future> Debug for Fuse<A>",synthetic:false,types:["futures::future::fuse::Fuse"]},{text:"impl<F: Debug + Future> Debug for IntoStream<F>",synthetic:false,types:["futures::future::into_stream::IntoStream"]},{text:"impl<A, B> Debug for Join<A, B> where
    A: Future + Debug,
    A::Item: Debug,
    B: Future<Error = A::Error> + Debug,
    B::Item: Debug
",synthetic:false,types:["futures::future::join::Join"]},{text:"impl<A, B, C> Debug for Join3<A, B, C> where
    A: Future + Debug,
    A::Item: Debug,
    B: Future<Error = A::Error> + Debug,
    B::Item: Debug,
    C: Future<Error = A::Error> + Debug,
    C::Item: Debug
",synthetic:false,types:["futures::future::join::Join3"]},{text:"impl<A, B, C, D> Debug for Join4<A, B, C, D> where
    A: Future + Debug,
    A::Item: Debug,
    B: Future<Error = A::Error> + Debug,
    B::Item: Debug,
    C: Future<Error = A::Error> + Debug,
    C::Item: Debug,
    D: Future<Error = A::Error> + Debug,
    D::Item: Debug
",synthetic:false,types:["futures::future::join::Join4"]},{text:"impl<A, B, C, D, E> Debug for Join5<A, B, C, D, E> where
    A: Future + Debug,
    A::Item: Debug,
    B: Future<Error = A::Error> + Debug,
    B::Item: Debug,
    C: Future<Error = A::Error> + Debug,
    C::Item: Debug,
    D: Future<Error = A::Error> + Debug,
    D::Item: Debug,
    E: Future<Error = A::Error> + Debug,
    E::Item: Debug
",synthetic:false,types:["futures::future::join::Join5"]},{text:"impl<A: Debug, F: Debug> Debug for Map<A, F> where
    A: Future
",synthetic:false,types:["futures::future::map::Map"]},{text:"impl<A: Debug, F: Debug> Debug for MapErr<A, F> where
    A: Future
",synthetic:false,types:["futures::future::map_err::MapErr"]},{text:"impl<A: Debug, E: Debug> Debug for FromErr<A, E> where
    A: Future
",synthetic:false,types:["futures::future::from_err::FromErr"]},{text:"impl<A: Debug, B: Debug, F: Debug> Debug for OrElse<A, B, F> where
    A: Future,
    B: IntoFuture,
    B::Future: Debug
",synthetic:false,types:["futures::future::or_else::OrElse"]},{text:"impl<A: Debug, B: Debug> Debug for Select<A, B> where
    A: Future,
    B: Future<Item = A::Item, Error = A::Error>, 
",synthetic:false,types:["futures::future::select::Select"]},{text:"impl<A: Debug, B: Debug> Debug for SelectNext<A, B> where
    A: Future,
    B: Future<Item = A::Item, Error = A::Error>, 
",synthetic:false,types:["futures::future::select::SelectNext"]},{text:"impl<A: Debug, B: Debug> Debug for Select2<A, B>",synthetic:false,types:["futures::future::select2::Select2"]},{text:"impl<A: Debug, B: Debug, F: Debug> Debug for Then<A, B, F> where
    A: Future,
    B: IntoFuture,
    B::Future: Debug
",synthetic:false,types:["futures::future::then::Then"]},{text:"impl<A: Debug, B: Debug> Debug for Either<A, B>",synthetic:false,types:["futures::future::either::Either"]},{text:"impl<A: Debug, F: Debug> Debug for Inspect<A, F> where
    A: Future
",synthetic:false,types:["futures::future::inspect::Inspect"]},{text:"impl<F: Debug> Debug for CatchUnwind<F> where
    F: Future
",synthetic:false,types:["futures::future::catch_unwind::CatchUnwind"]},{text:"impl<I> Debug for JoinAll<I> where
    I: IntoIterator,
    I::Item: IntoFuture,
    <<I as IntoIterator>::Item as IntoFuture>::Future: Debug,
    <<I as IntoIterator>::Item as IntoFuture>::Item: Debug
",synthetic:false,types:["futures::future::join_all::JoinAll"]},{text:"impl<A: Debug> Debug for SelectAll<A> where
    A: Future
",synthetic:false,types:["futures::future::select_all::SelectAll"]},{text:"impl<A: Debug> Debug for SelectOk<A> where
    A: Future
",synthetic:false,types:["futures::future::select_ok::SelectOk"]},{text:"impl<F> Debug for Shared<F> where
    F: Future + Debug,
    F::Item: Debug,
    F::Error: Debug
",synthetic:false,types:["futures::future::shared::Shared"]},{text:"impl<T: Debug> Debug for SharedItem<T>",synthetic:false,types:["futures::future::shared::SharedItem"]},{text:"impl<E: Debug> Debug for SharedError<E>",synthetic:false,types:["futures::future::shared::SharedError"]},{text:"impl Debug for ExecuteErrorKind",synthetic:false,types:["futures::future::ExecuteErrorKind"]},{text:"impl<F> Debug for ExecuteError<F>",synthetic:false,types:["futures::future::ExecuteError"]},{text:"impl<I: Debug> Debug for Iter<I>",synthetic:false,types:["futures::stream::iter::Iter"]},{text:"impl<I: Debug, E: Debug> Debug for IterOk<I, E>",synthetic:false,types:["futures::stream::iter_ok::IterOk"]},{text:"impl<I: Debug> Debug for IterResult<I>",synthetic:false,types:["futures::stream::iter_result::IterResult"]},{text:"impl<T: Debug, E: Debug> Debug for Repeat<T, E> where
    T: Clone
",synthetic:false,types:["futures::stream::repeat::Repeat"]},{text:"impl<S: Debug, F: Debug, U: Debug> Debug for AndThen<S, F, U> where
    U: IntoFuture,
    U::Future: Debug
",synthetic:false,types:["futures::stream::and_then::AndThen"]},{text:"impl<S1: Debug, S2: Debug> Debug for Chain<S1, S2>",synthetic:false,types:["futures::stream::chain::Chain"]},{text:"impl<S: Debug> Debug for Concat2<S> where
    S: Stream,
    S::Item: Debug
",synthetic:false,types:["futures::stream::concat::Concat2"]},{text:"impl<S: Debug> Debug for Concat<S> where
    S: Stream,
    S::Item: Debug
",synthetic:false,types:["futures::stream::concat::Concat"]},{text:"impl<T: Debug, E: Debug> Debug for Empty<T, E>",synthetic:false,types:["futures::stream::empty::Empty"]},{text:"impl<S: Debug, F: Debug> Debug for Filter<S, F>",synthetic:false,types:["futures::stream::filter::Filter"]},{text:"impl<S: Debug, F: Debug> Debug for FilterMap<S, F>",synthetic:false,types:["futures::stream::filter_map::FilterMap"]},{text:"impl<S: Debug> Debug for Flatten<S> where
    S: Stream,
    S::Item: Debug
",synthetic:false,types:["futures::stream::flatten::Flatten"]},{text:"impl<S: Debug, F: Debug, Fut: Debug, T: Debug> Debug for Fold<S, F, Fut, T> where
    Fut: IntoFuture,
    Fut::Future: Debug
",synthetic:false,types:["futures::stream::fold::Fold"]},{text:"impl<S: Debug, F: Debug, U: Debug> Debug for ForEach<S, F, U> where
    U: IntoFuture,
    U::Future: Debug
",synthetic:false,types:["futures::stream::for_each::ForEach"]},{text:"impl<S: Debug, E: Debug> Debug for FromErr<S, E>",synthetic:false,types:["futures::stream::from_err::FromErr"]},{text:"impl<S: Debug> Debug for Fuse<S>",synthetic:false,types:["futures::stream::fuse::Fuse"]},{text:"impl<S: Debug> Debug for StreamFuture<S>",synthetic:false,types:["futures::stream::future::StreamFuture"]},{text:"impl<S: Debug, F: Debug> Debug for Inspect<S, F> where
    S: Stream
",synthetic:false,types:["futures::stream::inspect::Inspect"]},{text:"impl<S: Debug, F: Debug> Debug for InspectErr<S, F> where
    S: Stream
",synthetic:false,types:["futures::stream::inspect_err::InspectErr"]},{text:"impl<S: Debug, F: Debug> Debug for Map<S, F>",synthetic:false,types:["futures::stream::map::Map"]},{text:"impl<S: Debug, F: Debug> Debug for MapErr<S, F>",synthetic:false,types:["futures::stream::map_err::MapErr"]},{text:"impl<S1: Debug, S2: Debug + Stream> Debug for Merge<S1, S2> where
    S2::Error: Debug
",synthetic:false,types:["futures::stream::merge::Merge"]},{text:"impl<I1: Debug, I2: Debug> Debug for MergedItem<I1, I2>",synthetic:false,types:["futures::stream::merge::MergedItem"]},{text:"impl<T: Debug, E: Debug> Debug for Once<T, E>",synthetic:false,types:["futures::stream::once::Once"]},{text:"impl<S: Debug, F: Debug, U: Debug> Debug for OrElse<S, F, U> where
    U: IntoFuture,
    U::Future: Debug
",synthetic:false,types:["futures::stream::or_else::OrElse"]},{text:"impl<S: Debug + Stream> Debug for Peekable<S> where
    S::Item: Debug
",synthetic:false,types:["futures::stream::peek::Peekable"]},{text:"impl<F: Debug> Debug for PollFn<F>",synthetic:false,types:["futures::stream::poll_fn::PollFn"]},{text:"impl<S1: Debug, S2: Debug> Debug for Select<S1, S2>",synthetic:false,types:["futures::stream::select::Select"]},{text:"impl<S: Debug> Debug for Skip<S>",synthetic:false,types:["futures::stream::skip::Skip"]},{text:"impl<S: Debug, P: Debug, R: Debug> Debug for SkipWhile<S, P, R> where
    S: Stream,
    R: IntoFuture,
    R::Future: Debug,
    S::Item: Debug
",synthetic:false,types:["futures::stream::skip_while::SkipWhile"]},{text:"impl<S: Debug> Debug for Take<S>",synthetic:false,types:["futures::stream::take::Take"]},{text:"impl<S: Debug, P: Debug, R: Debug> Debug for TakeWhile<S, P, R> where
    S: Stream,
    R: IntoFuture,
    R::Future: Debug,
    S::Item: Debug
",synthetic:false,types:["futures::stream::take_while::TakeWhile"]},{text:"impl<S: Debug, F: Debug, U: Debug> Debug for Then<S, F, U> where
    U: IntoFuture,
    U::Future: Debug
",synthetic:false,types:["futures::stream::then::Then"]},{text:"impl<T: Debug, F: Debug, Fut: Debug> Debug for Unfold<T, F, Fut> where
    Fut: IntoFuture,
    Fut::Future: Debug
",synthetic:false,types:["futures::stream::unfold::Unfold"]},{text:"impl<S1: Debug + Stream, S2: Debug + Stream> Debug for Zip<S1, S2> where
    S1::Item: Debug,
    S2::Item: Debug
",synthetic:false,types:["futures::stream::zip::Zip"]},{text:"impl<T: Debug + Stream, U: Debug> Debug for Forward<T, U> where
    T::Item: Debug
",synthetic:false,types:["futures::stream::forward::Forward"]},{text:"impl<S> Debug for Buffered<S> where
    S: Stream + Debug,
    S::Item: IntoFuture,
    <<S as Stream>::Item as IntoFuture>::Future: Debug,
    <<S as Stream>::Item as IntoFuture>::Item: Debug,
    <<S as Stream>::Item as IntoFuture>::Error: Debug
",synthetic:false,types:["futures::stream::buffered::Buffered"]},{text:"impl<S> Debug for BufferUnordered<S> where
    S: Stream + Debug,
    S::Item: IntoFuture,
    <<S as Stream>::Item as IntoFuture>::Future: Debug
",synthetic:false,types:["futures::stream::buffer_unordered::BufferUnordered"]},{text:"impl<S: Debug> Debug for CatchUnwind<S> where
    S: Stream
",synthetic:false,types:["futures::stream::catch_unwind::CatchUnwind"]},{text:"impl<S: Debug> Debug for Chunks<S> where
    S: Stream,
    S::Item: Debug,
    S::Error: Debug
",synthetic:false,types:["futures::stream::chunks::Chunks"]},{text:"impl<S: Debug> Debug for Collect<S> where
    S: Stream,
    S::Item: Debug
",synthetic:false,types:["futures::stream::collect::Collect"]},{text:"impl<S: Debug> Debug for Wait<S>",synthetic:false,types:["futures::stream::wait::Wait"]},{text:"impl<S: Debug> Debug for SplitStream<S>",synthetic:false,types:["futures::stream::split::SplitStream"]},{text:"impl<S: Debug> Debug for SplitSink<S>",synthetic:false,types:["futures::stream::split::SplitSink"]},{text:"impl<T> Debug for ReuniteError<T>",synthetic:false,types:["futures::stream::split::ReuniteError"]},{text:"impl<T: Debug> Debug for FuturesUnordered<T>",synthetic:false,types:["futures::stream::futures_unordered::FuturesUnordered"]},{text:"impl<'a, F: Debug + 'a> Debug for IterMut<'a, F>",synthetic:false,types:["futures::stream::futures_unordered::IterMut"]},{text:"impl<T: Debug> Debug for FuturesOrdered<T> where
    T: Future
",synthetic:false,types:["futures::stream::futures_ordered::FuturesOrdered"]},{text:"impl<S: Debug, U: Debug, F: Debug, Fut: Debug> Debug for With<S, U, F, Fut> where
    S: Sink,
    F: FnMut(U) -> Fut,
    Fut: IntoFuture,
    Fut::Future: Debug,
    S::SinkItem: Debug
",synthetic:false,types:["futures::sink::with::With"]},{text:"impl<S: Debug, U: Debug, F: Debug, St: Debug> Debug for WithFlatMap<S, U, F, St> where
    S: Sink,
    F: FnMut(U) -> St,
    St: Stream<Item = S::SinkItem, Error = S::SinkError>,
    S::SinkItem: Debug
",synthetic:false,types:["futures::sink::with_flat_map::WithFlatMap"]},{text:"impl<S: Debug> Debug for Flush<S>",synthetic:false,types:["futures::sink::flush::Flush"]},{text:"impl<S: Debug, E: Debug> Debug for SinkFromErr<S, E>",synthetic:false,types:["futures::sink::from_err::SinkFromErr"]},{text:"impl<S: Debug + Sink> Debug for Send<S> where
    S::SinkItem: Debug
",synthetic:false,types:["futures::sink::send::Send"]},{text:"impl<T: Debug, U: Debug + Stream> Debug for SendAll<T, U> where
    U::Item: Debug
",synthetic:false,types:["futures::sink::send_all::SendAll"]},{text:"impl<S: Debug, F: Debug> Debug for SinkMapErr<S, F>",synthetic:false,types:["futures::sink::map_err::SinkMapErr"]},{text:"impl<A: Sink + Debug, B: Sink + Debug> Debug for Fanout<A, B> where
    A::SinkItem: Debug,
    B::SinkItem: Debug
",synthetic:false,types:["futures::sink::fanout::Fanout"]},{text:"impl<S: Debug + Sink> Debug for Buffer<S> where
    S::SinkItem: Debug
",synthetic:false,types:["futures::sink::buffer::Buffer"]},{text:"impl<S: Debug> Debug for Wait<S>",synthetic:false,types:["futures::sink::wait::Wait"]},{text:"impl Debug for AtomicTask",synthetic:false,types:["futures::task_impl::atomic_task::AtomicTask"]},{text:"impl<T: Debug> Debug for LocalKey<T>",synthetic:false,types:["futures::task_impl::std::data::LocalKey"]},{text:"impl Debug for Run",synthetic:false,types:["futures::task_impl::std::Run"]},{text:"impl Debug for UnparkEvent",synthetic:false,types:["futures::task_impl::std::UnparkEvent"]},{text:"impl Debug for Task",synthetic:false,types:["futures::task_impl::Task"]},{text:"impl<T: Debug + ?Sized> Debug for Spawn<T>",synthetic:false,types:["futures::task_impl::Spawn"]},{text:"impl Debug for NotifyHandle",synthetic:false,types:["futures::task_impl::NotifyHandle"]},{text:"impl<T: Debug> Debug for Receiver<T>",synthetic:false,types:["futures::sync::oneshot::Receiver"]},{text:"impl<T: Debug> Debug for Sender<T>",synthetic:false,types:["futures::sync::oneshot::Sender"]},{text:"impl Debug for Canceled",synthetic:false,types:["futures::sync::oneshot::Canceled"]},{text:"impl<T: Debug, E: Debug> Debug for SpawnHandle<T, E>",synthetic:false,types:["futures::sync::oneshot::SpawnHandle"]},{text:"impl<F: Future + Debug> Debug for Execute<F>",synthetic:false,types:["futures::sync::oneshot::Execute"]},{text:"impl<T: Debug> Debug for Sender<T>",synthetic:false,types:["futures::sync::mpsc::Sender"]},{text:"impl<T: Debug> Debug for UnboundedSender<T>",synthetic:false,types:["futures::sync::mpsc::UnboundedSender"]},{text:"impl<T: Debug> Debug for Receiver<T>",synthetic:false,types:["futures::sync::mpsc::Receiver"]},{text:"impl<T: Debug> Debug for UnboundedReceiver<T>",synthetic:false,types:["futures::sync::mpsc::UnboundedReceiver"]},{text:"impl<T> Debug for SendError<T>",synthetic:false,types:["futures::sync::mpsc::SendError"]},{text:"impl<T> Debug for TrySendError<T>",synthetic:false,types:["futures::sync::mpsc::TrySendError"]},{text:"impl<I, E> Debug for SpawnHandle<I, E>",synthetic:false,types:["futures::sync::mpsc::SpawnHandle"]},{text:"impl<S: Stream> Debug for Execute<S>",synthetic:false,types:["futures::sync::mpsc::Execute"]},{text:"impl<T: Debug> Debug for BiLock<T>",synthetic:false,types:["futures::sync::bilock::BiLock"]},{text:"impl<'a, T: Debug + 'a> Debug for BiLockGuard<'a, T>",synthetic:false,types:["futures::sync::bilock::BiLockGuard"]},{text:"impl<T: Debug> Debug for BiLockAcquire<T>",synthetic:false,types:["futures::sync::bilock::BiLockAcquire"]},{text:"impl<T: Debug> Debug for BiLockAcquired<T>",synthetic:false,types:["futures::sync::bilock::BiLockAcquired"]},{text:"impl<T: Debug> Debug for Sender<T>",synthetic:false,types:["futures::unsync::mpsc::Sender"]},{text:"impl<T: Debug> Debug for Receiver<T>",synthetic:false,types:["futures::unsync::mpsc::Receiver"]},{text:"impl<T: Debug> Debug for UnboundedSender<T>",synthetic:false,types:["futures::unsync::mpsc::UnboundedSender"]},{text:"impl<T: Debug> Debug for UnboundedReceiver<T>",synthetic:false,types:["futures::unsync::mpsc::UnboundedReceiver"]},{text:"impl<T> Debug for SendError<T>",synthetic:false,types:["futures::unsync::mpsc::SendError"]},{text:"impl<I, E> Debug for SpawnHandle<I, E>",synthetic:false,types:["futures::unsync::mpsc::SpawnHandle"]},{text:"impl<S: Stream> Debug for Execute<S>",synthetic:false,types:["futures::unsync::mpsc::Execute"]},{text:"impl<T: Debug> Debug for Sender<T>",synthetic:false,types:["futures::unsync::oneshot::Sender"]},{text:"impl<T: Debug> Debug for Receiver<T>",synthetic:false,types:["futures::unsync::oneshot::Receiver"]},{text:"impl<T: Debug, E: Debug> Debug for SpawnHandle<T, E>",synthetic:false,types:["futures::unsync::oneshot::SpawnHandle"]},{text:"impl<F: Future + Debug> Debug for Execute<F>",synthetic:false,types:["futures::unsync::oneshot::Execute"]},]; implementors["num_bigint"] = [{text:"impl Debug for BigUint",synthetic:false,types:["num_bigint::biguint::BigUint"]},{text:"impl Debug for Sign",synthetic:false,types:["num_bigint::bigint::Sign"]},{text:"impl Debug for BigInt",synthetic:false,types:["num_bigint::bigint::BigInt"]},{text:"impl Debug for ParseBigIntError",synthetic:false,types:["num_bigint::ParseBigIntError"]},]; implementors["num_complex"] = [{text:"impl<T: Debug> Debug for Complex<T>",synthetic:false,types:["num_complex::Complex"]},{text:"impl<E: Debug> Debug for ParseComplexError<E>",synthetic:false,types:["num_complex::ParseComplexError"]},]; implementors["num_rational"] = [{text:"impl<T: Debug> Debug for Ratio<T>",synthetic:false,types:["num_rational::Ratio"]},{text:"impl Debug for ParseRatioError",synthetic:false,types:["num_rational::ParseRatioError"]},]; implementors["num_traits"] = [{text:"impl Debug for FloatErrorKind",synthetic:false,types:["num_traits::FloatErrorKind"]},{text:"impl Debug for ParseFloatError",synthetic:false,types:["num_traits::ParseFloatError"]},]; implementors["ocl"] = [{text:"impl Debug for Extensions",synthetic:false,types:["ocl::standard::platform::Extensions"]},{text:"impl Debug for Platform",synthetic:false,types:["ocl::standard::platform::Platform"]},{text:"impl Debug for DeviceSpecifier",synthetic:false,types:["ocl::standard::device::DeviceSpecifier"]},{text:"impl Debug for Device",synthetic:false,types:["ocl::standard::device::Device"]},{text:"impl Debug for Context",synthetic:false,types:["ocl::standard::context::Context"]},{text:"impl Debug for Program",synthetic:false,types:["ocl::standard::program::Program"]},{text:"impl Debug for BuildOpt",synthetic:false,types:["ocl::standard::program::BuildOpt"]},{text:"impl<'b> Debug for ProgramBuilder<'b>",synthetic:false,types:["ocl::standard::program::ProgramBuilder"]},{text:"impl Debug for Kernel",synthetic:false,types:["ocl::standard::kernel::Kernel"]},{text:"impl<'b> Debug for KernelBuilder<'b>",synthetic:false,types:["ocl::standard::kernel::KernelBuilder"]},{text:"impl Debug for Queue",synthetic:false,types:["ocl::standard::queue::Queue"]},{text:"impl Debug for BufferCmdError",synthetic:false,types:["ocl::standard::buffer::BufferCmdError"]},{text:"impl<T: Debug + OclPrm> Debug for Buffer<T>",synthetic:false,types:["ocl::standard::buffer::Buffer"]},{text:"impl<'a, T: Debug> Debug for BufferBuilder<'a, T> where
    T: OclPrm
",synthetic:false,types:["ocl::standard::buffer::BufferBuilder"]},{text:"impl<'c, T: Debug + 'c> Debug for ImageCmdKind<'c, T>",synthetic:false,types:["ocl::standard::image::ImageCmdKind"]},{text:"impl<T: Debug + OclPrm> Debug for Image<T>",synthetic:false,types:["ocl::standard::image::Image"]},{text:"impl Debug for Sampler",synthetic:false,types:["ocl::standard::sampler::Sampler"]},{text:"impl Debug for ProQue",synthetic:false,types:["ocl::standard::pro_que::ProQue"]},{text:"impl Debug for Event",synthetic:false,types:["ocl::standard::event::Event"]},{text:"impl Debug for EventArray",synthetic:false,types:["ocl::standard::event::EventArray"]},{text:"impl Debug for EventList",synthetic:false,types:["ocl::standard::event::EventList"]},{text:"impl Debug for SpatialDims",synthetic:false,types:["ocl::standard::spatial_dims::SpatialDims"]},{text:"impl<'a> Debug for ClWaitListPtrEnum<'a>",synthetic:false,types:["ocl::standard::types::ClWaitListPtrEnum"]},{text:"impl<'a> Debug for ClNullEventPtrEnum<'a>",synthetic:false,types:["ocl::standard::types::ClNullEventPtrEnum"]},{text:"impl Debug for ErrorKind",synthetic:false,types:["ocl::error::ErrorKind"]},{text:"impl Debug for Error",synthetic:false,types:["ocl::error::Error"]},{text:"impl<T: Debug + OclPrm> Debug for FutureMemMap<T>",synthetic:false,types:["ocl::async::future_mem_map::FutureMemMap"]},{text:"impl<V: Debug> Debug for ReadGuard<V>",synthetic:false,types:["ocl::async::order_lock::ReadGuard"]},{text:"impl<V: Debug> Debug for WriteGuard<V>",synthetic:false,types:["ocl::async::order_lock::WriteGuard"]},{text:"impl<V: Debug, G: Debug> Debug for FutureGuard<V, G> where
    G: OrderGuard<V>, 
",synthetic:false,types:["ocl::async::order_lock::FutureGuard"]},{text:"impl<V: Debug> Debug for OrderLock<V>",synthetic:false,types:["ocl::async::order_lock::OrderLock"]},{text:"impl<T: Debug> Debug for RwVec<T>",synthetic:false,types:["ocl::async::rw_vec::RwVec"]},{text:"impl<T: Debug> Debug for MemMap<T> where
    T: OclPrm
",synthetic:false,types:["ocl::async::mem_map::MemMap"]},{text:"impl<T: Debug + OclPrm> Debug for FutureFlush<T>",synthetic:false,types:["ocl::async::buffer_sink::FutureFlush"]},{text:"impl<T: Debug + OclPrm> Debug for Inner<T>",synthetic:false,types:["ocl::async::buffer_sink::Inner"]},{text:"impl<T: Debug + OclPrm> Debug for BufferSink<T>",synthetic:false,types:["ocl::async::buffer_sink::BufferSink"]},{text:"impl<T: Debug + OclPrm> Debug for FutureFlood<T>",synthetic:false,types:["ocl::async::buffer_stream::FutureFlood"]},{text:"impl<T: Debug + OclPrm> Debug for Inner<T>",synthetic:false,types:["ocl::async::buffer_stream::Inner"]},{text:"impl<T: Debug + OclPrm> Debug for BufferStream<T>",synthetic:false,types:["ocl::async::buffer_stream::BufferStream"]},]; implementors["ocl_core"] = [{text:"impl Debug for PlatformId",synthetic:false,types:["ocl_core::types::abs::PlatformId"]},{text:"impl Debug for DeviceId",synthetic:false,types:["ocl_core::types::abs::DeviceId"]},{text:"impl Debug for Context",synthetic:false,types:["ocl_core::types::abs::Context"]},{text:"impl Debug for CommandQueue",synthetic:false,types:["ocl_core::types::abs::CommandQueue"]},{text:"impl Debug for Mem",synthetic:false,types:["ocl_core::types::abs::Mem"]},{text:"impl<T: Debug> Debug for MemMap<T>",synthetic:false,types:["ocl_core::types::abs::MemMap"]},{text:"impl Debug for Program",synthetic:false,types:["ocl_core::types::abs::Program"]},{text:"impl Debug for Kernel",synthetic:false,types:["ocl_core::types::abs::Kernel"]},{text:"impl Debug for Event",synthetic:false,types:["ocl_core::types::abs::Event"]},{text:"impl Debug for Sampler",synthetic:false,types:["ocl_core::types::abs::Sampler"]},{text:"impl Debug for EmptyInfoResultError",synthetic:false,types:["ocl_core::types::enums::EmptyInfoResultError"]},{text:"impl Debug for PlatformInfoResult",synthetic:false,types:["ocl_core::types::enums::PlatformInfoResult"]},{text:"impl Debug for DeviceInfoResult",synthetic:false,types:["ocl_core::types::enums::DeviceInfoResult"]},{text:"impl Debug for ContextInfoResult",synthetic:false,types:["ocl_core::types::enums::ContextInfoResult"]},{text:"impl Debug for GlContextInfoResult",synthetic:false,types:["ocl_core::types::enums::GlContextInfoResult"]},{text:"impl Debug for CommandQueueInfoResult",synthetic:false,types:["ocl_core::types::enums::CommandQueueInfoResult"]},{text:"impl Debug for MemInfoResult",synthetic:false,types:["ocl_core::types::enums::MemInfoResult"]},{text:"impl Debug for ImageInfoResult",synthetic:false,types:["ocl_core::types::enums::ImageInfoResult"]},{text:"impl Debug for SamplerInfoResult",synthetic:false,types:["ocl_core::types::enums::SamplerInfoResult"]},{text:"impl Debug for ProgramInfoResult",synthetic:false,types:["ocl_core::types::enums::ProgramInfoResult"]},{text:"impl Debug for ProgramBuildInfoResult",synthetic:false,types:["ocl_core::types::enums::ProgramBuildInfoResult"]},{text:"impl Debug for KernelInfoResult",synthetic:false,types:["ocl_core::types::enums::KernelInfoResult"]},{text:"impl Debug for KernelArgInfoResult",synthetic:false,types:["ocl_core::types::enums::KernelArgInfoResult"]},{text:"impl Debug for KernelWorkGroupInfoResult",synthetic:false,types:["ocl_core::types::enums::KernelWorkGroupInfoResult"]},{text:"impl Debug for EventInfoResult",synthetic:false,types:["ocl_core::types::enums::EventInfoResult"]},{text:"impl Debug for ProfilingInfoResult",synthetic:false,types:["ocl_core::types::enums::ProfilingInfoResult"]},{text:"impl<'a> Debug for ArgVal<'a>",synthetic:false,types:["ocl_core::types::structs::ArgVal"]},{text:"impl Debug for OpenclVersion",synthetic:false,types:["ocl_core::types::structs::OpenclVersion"]},{text:"impl Debug for ContextPropertyValue",synthetic:false,types:["ocl_core::types::structs::ContextPropertyValue"]},{text:"impl Debug for ContextProperties",synthetic:false,types:["ocl_core::types::structs::ContextProperties"]},{text:"impl Debug for ImageFormatParseError",synthetic:false,types:["ocl_core::types::structs::ImageFormatParseError"]},{text:"impl Debug for ImageFormat",synthetic:false,types:["ocl_core::types::structs::ImageFormat"]},{text:"impl Debug for ImageDescriptor",synthetic:false,types:["ocl_core::types::structs::ImageDescriptor"]},{text:"impl Debug for ErrorKind",synthetic:false,types:["ocl_core::error::ErrorKind"]},{text:"impl Debug for Error",synthetic:false,types:["ocl_core::error::Error"]},{text:"impl Debug for UtilError",synthetic:false,types:["ocl_core::util::UtilError"]},{text:"impl Debug for VecRemoveRebuildError",synthetic:false,types:["ocl_core::util::VecRemoveRebuildError"]},{text:"impl Debug for DeviceType",synthetic:false,types:["ocl_core::DeviceType"]},{text:"impl Debug for DeviceFpConfig",synthetic:false,types:["ocl_core::DeviceFpConfig"]},{text:"impl Debug for DeviceExecCapabilities",synthetic:false,types:["ocl_core::DeviceExecCapabilities"]},{text:"impl Debug for CommandQueueProperties",synthetic:false,types:["ocl_core::CommandQueueProperties"]},{text:"impl Debug for DeviceAffinityDomain",synthetic:false,types:["ocl_core::DeviceAffinityDomain"]},{text:"impl Debug for MemFlags",synthetic:false,types:["ocl_core::MemFlags"]},{text:"impl Debug for MemMigrationFlags",synthetic:false,types:["ocl_core::MemMigrationFlags"]},{text:"impl Debug for MapFlags",synthetic:false,types:["ocl_core::MapFlags"]},{text:"impl Debug for ProgramBinaryType",synthetic:false,types:["ocl_core::ProgramBinaryType"]},{text:"impl Debug for KernelArgTypeQualifier",synthetic:false,types:["ocl_core::KernelArgTypeQualifier"]},{text:"impl Debug for Status",synthetic:false,types:["ocl_core::Status"]},{text:"impl Debug for GlTextureTarget",synthetic:false,types:["ocl_core::GlTextureTarget"]},{text:"impl Debug for ClGlObjectType",synthetic:false,types:["ocl_core::ClGlObjectType"]},{text:"impl Debug for ImageChannelOrder",synthetic:false,types:["ocl_core::ImageChannelOrder"]},{text:"impl Debug for ImageChannelDataType",synthetic:false,types:["ocl_core::ImageChannelDataType"]},{text:"impl Debug for Cbool",synthetic:false,types:["ocl_core::Cbool"]},{text:"impl Debug for Polling",synthetic:false,types:["ocl_core::Polling"]},{text:"impl Debug for PlatformInfo",synthetic:false,types:["ocl_core::PlatformInfo"]},{text:"impl Debug for DeviceInfo",synthetic:false,types:["ocl_core::DeviceInfo"]},{text:"impl Debug for DeviceMemCacheType",synthetic:false,types:["ocl_core::DeviceMemCacheType"]},{text:"impl Debug for DeviceLocalMemType",synthetic:false,types:["ocl_core::DeviceLocalMemType"]},{text:"impl Debug for ContextInfo",synthetic:false,types:["ocl_core::ContextInfo"]},{text:"impl Debug for GlContextInfo",synthetic:false,types:["ocl_core::GlContextInfo"]},{text:"impl Debug for ContextProperty",synthetic:false,types:["ocl_core::ContextProperty"]},{text:"impl Debug for ContextInfoOrPropertiesPointerType",synthetic:false,types:["ocl_core::ContextInfoOrPropertiesPointerType"]},{text:"impl Debug for DevicePartitionProperty",synthetic:false,types:["ocl_core::DevicePartitionProperty"]},{text:"impl Debug for CommandQueueInfo",synthetic:false,types:["ocl_core::CommandQueueInfo"]},{text:"impl Debug for ChannelType",synthetic:false,types:["ocl_core::ChannelType"]},{text:"impl Debug for MemObjectType",synthetic:false,types:["ocl_core::MemObjectType"]},{text:"impl Debug for MemInfo",synthetic:false,types:["ocl_core::MemInfo"]},{text:"impl Debug for ImageInfo",synthetic:false,types:["ocl_core::ImageInfo"]},{text:"impl Debug for AddressingMode",synthetic:false,types:["ocl_core::AddressingMode"]},{text:"impl Debug for FilterMode",synthetic:false,types:["ocl_core::FilterMode"]},{text:"impl Debug for SamplerInfo",synthetic:false,types:["ocl_core::SamplerInfo"]},{text:"impl Debug for ProgramInfo",synthetic:false,types:["ocl_core::ProgramInfo"]},{text:"impl Debug for ProgramBuildInfo",synthetic:false,types:["ocl_core::ProgramBuildInfo"]},{text:"impl Debug for ProgramBuildStatus",synthetic:false,types:["ocl_core::ProgramBuildStatus"]},{text:"impl Debug for KernelInfo",synthetic:false,types:["ocl_core::KernelInfo"]},{text:"impl Debug for KernelArgInfo",synthetic:false,types:["ocl_core::KernelArgInfo"]},{text:"impl Debug for KernelArgAddressQualifier",synthetic:false,types:["ocl_core::KernelArgAddressQualifier"]},{text:"impl Debug for KernelArgAccessQualifier",synthetic:false,types:["ocl_core::KernelArgAccessQualifier"]},{text:"impl Debug for KernelWorkGroupInfo",synthetic:false,types:["ocl_core::KernelWorkGroupInfo"]},{text:"impl Debug for EventInfo",synthetic:false,types:["ocl_core::EventInfo"]},{text:"impl Debug for CommandType",synthetic:false,types:["ocl_core::CommandType"]},{text:"impl Debug for CommandExecutionStatus",synthetic:false,types:["ocl_core::CommandExecutionStatus"]},{text:"impl Debug for BufferCreateType",synthetic:false,types:["ocl_core::BufferCreateType"]},{text:"impl Debug for ProfilingInfo",synthetic:false,types:["ocl_core::ProfilingInfo"]},]; implementors["ocl_core_vector"] = [{text:"impl Debug for Char",synthetic:false,types:["ocl_core_vector::vectors::Char"]},{text:"impl Debug for Char2",synthetic:false,types:["ocl_core_vector::vectors::Char2"]},{text:"impl Debug for Char3",synthetic:false,types:["ocl_core_vector::vectors::Char3"]},{text:"impl Debug for Char4",synthetic:false,types:["ocl_core_vector::vectors::Char4"]},{text:"impl Debug for Char8",synthetic:false,types:["ocl_core_vector::vectors::Char8"]},{text:"impl Debug for Char16",synthetic:false,types:["ocl_core_vector::vectors::Char16"]},{text:"impl Debug for Uchar",synthetic:false,types:["ocl_core_vector::vectors::Uchar"]},{text:"impl Debug for Uchar2",synthetic:false,types:["ocl_core_vector::vectors::Uchar2"]},{text:"impl Debug for Uchar3",synthetic:false,types:["ocl_core_vector::vectors::Uchar3"]},{text:"impl Debug for Uchar4",synthetic:false,types:["ocl_core_vector::vectors::Uchar4"]},{text:"impl Debug for Uchar8",synthetic:false,types:["ocl_core_vector::vectors::Uchar8"]},{text:"impl Debug for Uchar16",synthetic:false,types:["ocl_core_vector::vectors::Uchar16"]},{text:"impl Debug for Short",synthetic:false,types:["ocl_core_vector::vectors::Short"]},{text:"impl Debug for Short2",synthetic:false,types:["ocl_core_vector::vectors::Short2"]},{text:"impl Debug for Short3",synthetic:false,types:["ocl_core_vector::vectors::Short3"]},{text:"impl Debug for Short4",synthetic:false,types:["ocl_core_vector::vectors::Short4"]},{text:"impl Debug for Short8",synthetic:false,types:["ocl_core_vector::vectors::Short8"]},{text:"impl Debug for Short16",synthetic:false,types:["ocl_core_vector::vectors::Short16"]},{text:"impl Debug for Ushort",synthetic:false,types:["ocl_core_vector::vectors::Ushort"]},{text:"impl Debug for Ushort2",synthetic:false,types:["ocl_core_vector::vectors::Ushort2"]},{text:"impl Debug for Ushort3",synthetic:false,types:["ocl_core_vector::vectors::Ushort3"]},{text:"impl Debug for Ushort4",synthetic:false,types:["ocl_core_vector::vectors::Ushort4"]},{text:"impl Debug for Ushort8",synthetic:false,types:["ocl_core_vector::vectors::Ushort8"]},{text:"impl Debug for Ushort16",synthetic:false,types:["ocl_core_vector::vectors::Ushort16"]},{text:"impl Debug for Int",synthetic:false,types:["ocl_core_vector::vectors::Int"]},{text:"impl Debug for Int2",synthetic:false,types:["ocl_core_vector::vectors::Int2"]},{text:"impl Debug for Int3",synthetic:false,types:["ocl_core_vector::vectors::Int3"]},{text:"impl Debug for Int4",synthetic:false,types:["ocl_core_vector::vectors::Int4"]},{text:"impl Debug for Int8",synthetic:false,types:["ocl_core_vector::vectors::Int8"]},{text:"impl Debug for Int16",synthetic:false,types:["ocl_core_vector::vectors::Int16"]},{text:"impl Debug for Uint",synthetic:false,types:["ocl_core_vector::vectors::Uint"]},{text:"impl Debug for Uint2",synthetic:false,types:["ocl_core_vector::vectors::Uint2"]},{text:"impl Debug for Uint3",synthetic:false,types:["ocl_core_vector::vectors::Uint3"]},{text:"impl Debug for Uint4",synthetic:false,types:["ocl_core_vector::vectors::Uint4"]},{text:"impl Debug for Uint8",synthetic:false,types:["ocl_core_vector::vectors::Uint8"]},{text:"impl Debug for Uint16",synthetic:false,types:["ocl_core_vector::vectors::Uint16"]},{text:"impl Debug for Long",synthetic:false,types:["ocl_core_vector::vectors::Long"]},{text:"impl Debug for Long2",synthetic:false,types:["ocl_core_vector::vectors::Long2"]},{text:"impl Debug for Long3",synthetic:false,types:["ocl_core_vector::vectors::Long3"]},{text:"impl Debug for Long4",synthetic:false,types:["ocl_core_vector::vectors::Long4"]},{text:"impl Debug for Long8",synthetic:false,types:["ocl_core_vector::vectors::Long8"]},{text:"impl Debug for Long16",synthetic:false,types:["ocl_core_vector::vectors::Long16"]},{text:"impl Debug for Ulong",synthetic:false,types:["ocl_core_vector::vectors::Ulong"]},{text:"impl Debug for Ulong2",synthetic:false,types:["ocl_core_vector::vectors::Ulong2"]},{text:"impl Debug for Ulong3",synthetic:false,types:["ocl_core_vector::vectors::Ulong3"]},{text:"impl Debug for Ulong4",synthetic:false,types:["ocl_core_vector::vectors::Ulong4"]},{text:"impl Debug for Ulong8",synthetic:false,types:["ocl_core_vector::vectors::Ulong8"]},{text:"impl Debug for Ulong16",synthetic:false,types:["ocl_core_vector::vectors::Ulong16"]},{text:"impl Debug for Float",synthetic:false,types:["ocl_core_vector::vectors::Float"]},{text:"impl Debug for Float2",synthetic:false,types:["ocl_core_vector::vectors::Float2"]},{text:"impl Debug for Float3",synthetic:false,types:["ocl_core_vector::vectors::Float3"]},{text:"impl Debug for Float4",synthetic:false,types:["ocl_core_vector::vectors::Float4"]},{text:"impl Debug for Float8",synthetic:false,types:["ocl_core_vector::vectors::Float8"]},{text:"impl Debug for Float16",synthetic:false,types:["ocl_core_vector::vectors::Float16"]},{text:"impl Debug for Double",synthetic:false,types:["ocl_core_vector::vectors::Double"]},{text:"impl Debug for Double2",synthetic:false,types:["ocl_core_vector::vectors::Double2"]},{text:"impl Debug for Double3",synthetic:false,types:["ocl_core_vector::vectors::Double3"]},{text:"impl Debug for Double4",synthetic:false,types:["ocl_core_vector::vectors::Double4"]},{text:"impl Debug for Double8",synthetic:false,types:["ocl_core_vector::vectors::Double8"]},{text:"impl Debug for Double16",synthetic:false,types:["ocl_core_vector::vectors::Double16"]},]; implementors["proc_macro2"] = [{text:"impl Debug for IntoIter",synthetic:false,types:["proc_macro2::token_stream::IntoIter"]},{text:"impl Debug for TokenStream",synthetic:false,types:["proc_macro2::TokenStream"]},{text:"impl Debug for LexError",synthetic:false,types:["proc_macro2::LexError"]},{text:"impl Debug for Span",synthetic:false,types:["proc_macro2::Span"]},{text:"impl Debug for TokenTree",synthetic:false,types:["proc_macro2::TokenTree"]},{text:"impl Debug for Delimiter",synthetic:false,types:["proc_macro2::Delimiter"]},{text:"impl Debug for Group",synthetic:false,types:["proc_macro2::Group"]},{text:"impl Debug for Spacing",synthetic:false,types:["proc_macro2::Spacing"]},{text:"impl Debug for Punct",synthetic:false,types:["proc_macro2::Punct"]},{text:"impl Debug for Ident",synthetic:false,types:["proc_macro2::Ident"]},{text:"impl Debug for Literal",synthetic:false,types:["proc_macro2::Literal"]},]; implementors["qcgpu"] = [{text:"impl Debug for OpenCL",synthetic:false,types:["qcgpu::backends::opencl::OpenCL"]},{text:"impl Debug for Gate",synthetic:false,types:["qcgpu::gate::Gate"]},{text:"impl Debug for Simulator",synthetic:false,types:["qcgpu::Simulator"]},]; implementors["qutex"] = [{text:"impl<T: Debug> Debug for Guard<T>",synthetic:false,types:["qutex::qutex::Guard"]},{text:"impl<T: Debug> Debug for FutureGuard<T>",synthetic:false,types:["qutex::qutex::FutureGuard"]},{text:"impl Debug for Request",synthetic:false,types:["qutex::qutex::Request"]},{text:"impl<T: Debug> Debug for Qutex<T>",synthetic:false,types:["qutex::qutex::Qutex"]},{text:"impl<T: Debug> Debug for ReadGuard<T>",synthetic:false,types:["qutex::qrw_lock::ReadGuard"]},{text:"impl<T: Debug> Debug for WriteGuard<T>",synthetic:false,types:["qutex::qrw_lock::WriteGuard"]},{text:"impl<T: Debug> Debug for FutureReadGuard<T>",synthetic:false,types:["qutex::qrw_lock::FutureReadGuard"]},{text:"impl<T: Debug> Debug for FutureWriteGuard<T>",synthetic:false,types:["qutex::qrw_lock::FutureWriteGuard"]},{text:"impl Debug for RequestKind",synthetic:false,types:["qutex::qrw_lock::RequestKind"]},{text:"impl Debug for QrwRequest",synthetic:false,types:["qutex::qrw_lock::QrwRequest"]},{text:"impl<T: Debug> Debug for QrwLock<T>",synthetic:false,types:["qutex::qrw_lock::QrwLock"]},]; implementors["rand"] = [{text:"impl<X: Debug + SampleUniform> Debug for Uniform<X> where
    X::Sampler: Debug
",synthetic:false,types:["rand::distributions::uniform::Uniform"]},{text:"impl<X: Debug> Debug for UniformInt<X>",synthetic:false,types:["rand::distributions::uniform::UniformInt"]},{text:"impl<X: Debug> Debug for UniformFloat<X>",synthetic:false,types:["rand::distributions::uniform::UniformFloat"]},{text:"impl Debug for UniformDuration",synthetic:false,types:["rand::distributions::uniform::UniformDuration"]},{text:"impl Debug for Gamma",synthetic:false,types:["rand::distributions::gamma::Gamma"]},{text:"impl Debug for ChiSquared",synthetic:false,types:["rand::distributions::gamma::ChiSquared"]},{text:"impl Debug for FisherF",synthetic:false,types:["rand::distributions::gamma::FisherF"]},{text:"impl Debug for StudentT",synthetic:false,types:["rand::distributions::gamma::StudentT"]},{text:"impl Debug for StandardNormal",synthetic:false,types:["rand::distributions::normal::StandardNormal"]},{text:"impl Debug for Normal",synthetic:false,types:["rand::distributions::normal::Normal"]},{text:"impl Debug for LogNormal",synthetic:false,types:["rand::distributions::normal::LogNormal"]},{text:"impl Debug for Exp1",synthetic:false,types:["rand::distributions::exponential::Exp1"]},{text:"impl Debug for Exp",synthetic:false,types:["rand::distributions::exponential::Exp"]},{text:"impl Debug for Pareto",synthetic:false,types:["rand::distributions::pareto::Pareto"]},{text:"impl Debug for Poisson",synthetic:false,types:["rand::distributions::poisson::Poisson"]},{text:"impl Debug for Binomial",synthetic:false,types:["rand::distributions::binomial::Binomial"]},{text:"impl Debug for Bernoulli",synthetic:false,types:["rand::distributions::bernoulli::Bernoulli"]},{text:"impl Debug for Cauchy",synthetic:false,types:["rand::distributions::cauchy::Cauchy"]},{text:"impl Debug for OpenClosed01",synthetic:false,types:["rand::distributions::float::OpenClosed01"]},{text:"impl Debug for Open01",synthetic:false,types:["rand::distributions::float::Open01"]},{text:"impl Debug for Alphanumeric",synthetic:false,types:["rand::distributions::other::Alphanumeric"]},{text:"impl<'a, D: Debug + 'a, R: Debug + 'a, T: Debug> Debug for DistIter<'a, D, R, T>",synthetic:false,types:["rand::distributions::DistIter"]},{text:"impl Debug for Standard",synthetic:false,types:["rand::distributions::Standard"]},{text:"impl<T: Debug> Debug for Weighted<T>",synthetic:false,types:["rand::distributions::Weighted"]},{text:"impl<'a, T: Debug + 'a> Debug for WeightedChoice<'a, T>",synthetic:false,types:["rand::distributions::WeightedChoice"]},{text:"impl Debug for ChaChaRng",synthetic:false,types:["rand::prng::chacha::ChaChaRng"]},{text:"impl Debug for ChaChaCore",synthetic:false,types:["rand::prng::chacha::ChaChaCore"]},{text:"impl Debug for Hc128Rng",synthetic:false,types:["rand::prng::hc128::Hc128Rng"]},{text:"impl Debug for Hc128Core",synthetic:false,types:["rand::prng::hc128::Hc128Core"]},{text:"impl Debug for IsaacRng",synthetic:false,types:["rand::prng::isaac::IsaacRng"]},{text:"impl Debug for IsaacCore",synthetic:false,types:["rand::prng::isaac::IsaacCore"]},{text:"impl Debug for Isaac64Rng",synthetic:false,types:["rand::prng::isaac64::Isaac64Rng"]},{text:"impl Debug for Isaac64Core",synthetic:false,types:["rand::prng::isaac64::Isaac64Core"]},{text:"impl Debug for XorShiftRng",synthetic:false,types:["rand::prng::xorshift::XorShiftRng"]},{text:"impl<R: Debug> Debug for ReadRng<R>",synthetic:false,types:["rand::rngs::adapter::read::ReadRng"]},{text:"impl<R: Debug, Rsdr: Debug> Debug for ReseedingRng<R, Rsdr> where
    R: BlockRngCore + SeedableRng,
    Rsdr: RngCore
",synthetic:false,types:["rand::rngs::adapter::reseeding::ReseedingRng"]},{text:"impl Debug for EntropyRng",synthetic:false,types:["rand::rngs::entropy::EntropyRng"]},{text:"impl Debug for JitterRng",synthetic:false,types:["rand::rngs::jitter::JitterRng"]},{text:"impl Debug for TimerError",synthetic:false,types:["rand::rngs::jitter::TimerError"]},{text:"impl Debug for StepRng",synthetic:false,types:["rand::rngs::mock::StepRng"]},{text:"impl Debug for SmallRng",synthetic:false,types:["rand::rngs::small::SmallRng"]},{text:"impl Debug for StdRng",synthetic:false,types:["rand::rngs::std::StdRng"]},{text:"impl Debug for ThreadRng",synthetic:false,types:["rand::rngs::thread::ThreadRng"]},{text:"impl Debug for OsRng",synthetic:false,types:["rand::rngs::os::OsRng"]},{text:"impl<T: Debug, R: Debug + RngCore> Debug for Generator<T, R>",synthetic:false,types:["rand::Generator"]},{text:"impl<R: Debug + RngCore> Debug for AsciiGenerator<R>",synthetic:false,types:["rand::AsciiGenerator"]},]; implementors["rand_core"] = [{text:"impl Debug for ErrorKind",synthetic:false,types:["rand_core::error::ErrorKind"]},{text:"impl Debug for Error",synthetic:false,types:["rand_core::error::Error"]},{text:"impl<R: BlockRngCore + Debug> Debug for BlockRng<R>",synthetic:false,types:["rand_core::block::BlockRng"]},{text:"impl<R: BlockRngCore + Debug> Debug for BlockRng64<R>",synthetic:false,types:["rand_core::block::BlockRng64"]},]; implementors["rustc_demangle"] = [{text:"impl Debug for TryDemangleError",synthetic:false,types:["rustc_demangle::TryDemangleError"]},{text:"impl<'a> Debug for Demangle<'a>",synthetic:false,types:["rustc_demangle::Demangle"]},]; implementors["rustc_serialize"] = [{text:"impl Debug for CharacterSet",synthetic:false,types:["rustc_serialize::base64::CharacterSet"]},{text:"impl Debug for Newline",synthetic:false,types:["rustc_serialize::base64::Newline"]},{text:"impl Debug for Config",synthetic:false,types:["rustc_serialize::base64::Config"]},{text:"impl Debug for FromBase64Error",synthetic:false,types:["rustc_serialize::base64::FromBase64Error"]},{text:"impl Debug for FromHexError",synthetic:false,types:["rustc_serialize::hex::FromHexError"]},{text:"impl Debug for Json",synthetic:false,types:["rustc_serialize::json::Json"]},{text:"impl Debug for ParserError",synthetic:false,types:["rustc_serialize::json::ParserError"]},{text:"impl Debug for DecoderError",synthetic:false,types:["rustc_serialize::json::DecoderError"]},{text:"impl Debug for EncoderError",synthetic:false,types:["rustc_serialize::json::EncoderError"]},{text:"impl Debug for ErrorCode",synthetic:false,types:["rustc_serialize::json::ErrorCode"]},{text:"impl Debug for JsonEvent",synthetic:false,types:["rustc_serialize::json::JsonEvent"]},{text:"impl<'l> Debug for StackElement<'l>",synthetic:false,types:["rustc_serialize::json::StackElement"]},]; implementors["syn"] = [{text:"impl Debug for Underscore",synthetic:false,types:["syn::token::Underscore"]},{text:"impl Debug for Apostrophe",synthetic:false,types:["syn::token::Apostrophe"]},{text:"impl Debug for Add",synthetic:false,types:["syn::token::Add"]},{text:"impl Debug for AddEq",synthetic:false,types:["syn::token::AddEq"]},{text:"impl Debug for And",synthetic:false,types:["syn::token::And"]},{text:"impl Debug for AndAnd",synthetic:false,types:["syn::token::AndAnd"]},{text:"impl Debug for AndEq",synthetic:false,types:["syn::token::AndEq"]},{text:"impl Debug for At",synthetic:false,types:["syn::token::At"]},{text:"impl Debug for Bang",synthetic:false,types:["syn::token::Bang"]},{text:"impl Debug for Caret",synthetic:false,types:["syn::token::Caret"]},{text:"impl Debug for CaretEq",synthetic:false,types:["syn::token::CaretEq"]},{text:"impl Debug for Colon",synthetic:false,types:["syn::token::Colon"]},{text:"impl Debug for Colon2",synthetic:false,types:["syn::token::Colon2"]},{text:"impl Debug for Comma",synthetic:false,types:["syn::token::Comma"]},{text:"impl Debug for Div",synthetic:false,types:["syn::token::Div"]},{text:"impl Debug for DivEq",synthetic:false,types:["syn::token::DivEq"]},{text:"impl Debug for Dollar",synthetic:false,types:["syn::token::Dollar"]},{text:"impl Debug for Dot",synthetic:false,types:["syn::token::Dot"]},{text:"impl Debug for Dot2",synthetic:false,types:["syn::token::Dot2"]},{text:"impl Debug for Dot3",synthetic:false,types:["syn::token::Dot3"]},{text:"impl Debug for DotDotEq",synthetic:false,types:["syn::token::DotDotEq"]},{text:"impl Debug for Eq",synthetic:false,types:["syn::token::Eq"]},{text:"impl Debug for EqEq",synthetic:false,types:["syn::token::EqEq"]},{text:"impl Debug for Ge",synthetic:false,types:["syn::token::Ge"]},{text:"impl Debug for Gt",synthetic:false,types:["syn::token::Gt"]},{text:"impl Debug for Le",synthetic:false,types:["syn::token::Le"]},{text:"impl Debug for Lt",synthetic:false,types:["syn::token::Lt"]},{text:"impl Debug for MulEq",synthetic:false,types:["syn::token::MulEq"]},{text:"impl Debug for Ne",synthetic:false,types:["syn::token::Ne"]},{text:"impl Debug for Or",synthetic:false,types:["syn::token::Or"]},{text:"impl Debug for OrEq",synthetic:false,types:["syn::token::OrEq"]},{text:"impl Debug for OrOr",synthetic:false,types:["syn::token::OrOr"]},{text:"impl Debug for Pound",synthetic:false,types:["syn::token::Pound"]},{text:"impl Debug for Question",synthetic:false,types:["syn::token::Question"]},{text:"impl Debug for RArrow",synthetic:false,types:["syn::token::RArrow"]},{text:"impl Debug for LArrow",synthetic:false,types:["syn::token::LArrow"]},{text:"impl Debug for Rem",synthetic:false,types:["syn::token::Rem"]},{text:"impl Debug for RemEq",synthetic:false,types:["syn::token::RemEq"]},{text:"impl Debug for FatArrow",synthetic:false,types:["syn::token::FatArrow"]},{text:"impl Debug for Semi",synthetic:false,types:["syn::token::Semi"]},{text:"impl Debug for Shl",synthetic:false,types:["syn::token::Shl"]},{text:"impl Debug for ShlEq",synthetic:false,types:["syn::token::ShlEq"]},{text:"impl Debug for Shr",synthetic:false,types:["syn::token::Shr"]},{text:"impl Debug for ShrEq",synthetic:false,types:["syn::token::ShrEq"]},{text:"impl Debug for Star",synthetic:false,types:["syn::token::Star"]},{text:"impl Debug for Sub",synthetic:false,types:["syn::token::Sub"]},{text:"impl Debug for SubEq",synthetic:false,types:["syn::token::SubEq"]},{text:"impl Debug for Brace",synthetic:false,types:["syn::token::Brace"]},{text:"impl Debug for Bracket",synthetic:false,types:["syn::token::Bracket"]},{text:"impl Debug for Paren",synthetic:false,types:["syn::token::Paren"]},{text:"impl Debug for Group",synthetic:false,types:["syn::token::Group"]},{text:"impl Debug for As",synthetic:false,types:["syn::token::As"]},{text:"impl Debug for Async",synthetic:false,types:["syn::token::Async"]},{text:"impl Debug for Auto",synthetic:false,types:["syn::token::Auto"]},{text:"impl Debug for Box",synthetic:false,types:["syn::token::Box"]},{text:"impl Debug for Break",synthetic:false,types:["syn::token::Break"]},{text:"impl Debug for CapSelf",synthetic:false,types:["syn::token::CapSelf"]},{text:"impl Debug for Catch",synthetic:false,types:["syn::token::Catch"]},{text:"impl Debug for Const",synthetic:false,types:["syn::token::Const"]},{text:"impl Debug for Continue",synthetic:false,types:["syn::token::Continue"]},{text:"impl Debug for Crate",synthetic:false,types:["syn::token::Crate"]},{text:"impl Debug for Default",synthetic:false,types:["syn::token::Default"]},{text:"impl Debug for Do",synthetic:false,types:["syn::token::Do"]},{text:"impl Debug for Dyn",synthetic:false,types:["syn::token::Dyn"]},{text:"impl Debug for Else",synthetic:false,types:["syn::token::Else"]},{text:"impl Debug for Enum",synthetic:false,types:["syn::token::Enum"]},{text:"impl Debug for Extern",synthetic:false,types:["syn::token::Extern"]},{text:"impl Debug for Fn",synthetic:false,types:["syn::token::Fn"]},{text:"impl Debug for For",synthetic:false,types:["syn::token::For"]},{text:"impl Debug for If",synthetic:false,types:["syn::token::If"]},{text:"impl Debug for Impl",synthetic:false,types:["syn::token::Impl"]},{text:"impl Debug for In",synthetic:false,types:["syn::token::In"]},{text:"impl Debug for Let",synthetic:false,types:["syn::token::Let"]},{text:"impl Debug for Loop",synthetic:false,types:["syn::token::Loop"]},{text:"impl Debug for Macro",synthetic:false,types:["syn::token::Macro"]},{text:"impl Debug for Match",synthetic:false,types:["syn::token::Match"]},{text:"impl Debug for Mod",synthetic:false,types:["syn::token::Mod"]},{text:"impl Debug for Move",synthetic:false,types:["syn::token::Move"]},{text:"impl Debug for Mut",synthetic:false,types:["syn::token::Mut"]},{text:"impl Debug for Pub",synthetic:false,types:["syn::token::Pub"]},{text:"impl Debug for Ref",synthetic:false,types:["syn::token::Ref"]},{text:"impl Debug for Return",synthetic:false,types:["syn::token::Return"]},{text:"impl Debug for Self_",synthetic:false,types:["syn::token::Self_"]},{text:"impl Debug for Static",synthetic:false,types:["syn::token::Static"]},{text:"impl Debug for Struct",synthetic:false,types:["syn::token::Struct"]},{text:"impl Debug for Super",synthetic:false,types:["syn::token::Super"]},{text:"impl Debug for Trait",synthetic:false,types:["syn::token::Trait"]},{text:"impl Debug for Type",synthetic:false,types:["syn::token::Type"]},{text:"impl Debug for Union",synthetic:false,types:["syn::token::Union"]},{text:"impl Debug for Unsafe",synthetic:false,types:["syn::token::Unsafe"]},{text:"impl Debug for Use",synthetic:false,types:["syn::token::Use"]},{text:"impl Debug for Where",synthetic:false,types:["syn::token::Where"]},{text:"impl Debug for While",synthetic:false,types:["syn::token::While"]},{text:"impl Debug for Yield",synthetic:false,types:["syn::token::Yield"]},{text:"impl Debug for Attribute",synthetic:false,types:["syn::attr::Attribute"]},{text:"impl Debug for AttrStyle",synthetic:false,types:["syn::attr::AttrStyle"]},{text:"impl Debug for Meta",synthetic:false,types:["syn::attr::Meta"]},{text:"impl Debug for MetaList",synthetic:false,types:["syn::attr::MetaList"]},{text:"impl Debug for MetaNameValue",synthetic:false,types:["syn::attr::MetaNameValue"]},{text:"impl Debug for NestedMeta",synthetic:false,types:["syn::attr::NestedMeta"]},{text:"impl Debug for Variant",synthetic:false,types:["syn::data::Variant"]},{text:"impl Debug for Fields",synthetic:false,types:["syn::data::Fields"]},{text:"impl Debug for FieldsNamed",synthetic:false,types:["syn::data::FieldsNamed"]},{text:"impl Debug for FieldsUnnamed",synthetic:false,types:["syn::data::FieldsUnnamed"]},{text:"impl Debug for Field",synthetic:false,types:["syn::data::Field"]},{text:"impl Debug for Visibility",synthetic:false,types:["syn::data::Visibility"]},{text:"impl Debug for VisPublic",synthetic:false,types:["syn::data::VisPublic"]},{text:"impl Debug for VisCrate",synthetic:false,types:["syn::data::VisCrate"]},{text:"impl Debug for VisRestricted",synthetic:false,types:["syn::data::VisRestricted"]},{text:"impl Debug for Expr",synthetic:false,types:["syn::expr::Expr"]},{text:"impl Debug for ExprBox",synthetic:false,types:["syn::expr::ExprBox"]},{text:"impl Debug for ExprInPlace",synthetic:false,types:["syn::expr::ExprInPlace"]},{text:"impl Debug for ExprArray",synthetic:false,types:["syn::expr::ExprArray"]},{text:"impl Debug for ExprCall",synthetic:false,types:["syn::expr::ExprCall"]},{text:"impl Debug for ExprMethodCall",synthetic:false,types:["syn::expr::ExprMethodCall"]},{text:"impl Debug for ExprTuple",synthetic:false,types:["syn::expr::ExprTuple"]},{text:"impl Debug for ExprBinary",synthetic:false,types:["syn::expr::ExprBinary"]},{text:"impl Debug for ExprUnary",synthetic:false,types:["syn::expr::ExprUnary"]},{text:"impl Debug for ExprLit",synthetic:false,types:["syn::expr::ExprLit"]},{text:"impl Debug for ExprCast",synthetic:false,types:["syn::expr::ExprCast"]},{text:"impl Debug for ExprType",synthetic:false,types:["syn::expr::ExprType"]},{text:"impl Debug for ExprIf",synthetic:false,types:["syn::expr::ExprIf"]},{text:"impl Debug for ExprIfLet",synthetic:false,types:["syn::expr::ExprIfLet"]},{text:"impl Debug for ExprWhile",synthetic:false,types:["syn::expr::ExprWhile"]},{text:"impl Debug for ExprWhileLet",synthetic:false,types:["syn::expr::ExprWhileLet"]},{text:"impl Debug for ExprForLoop",synthetic:false,types:["syn::expr::ExprForLoop"]},{text:"impl Debug for ExprLoop",synthetic:false,types:["syn::expr::ExprLoop"]},{text:"impl Debug for ExprMatch",synthetic:false,types:["syn::expr::ExprMatch"]},{text:"impl Debug for ExprClosure",synthetic:false,types:["syn::expr::ExprClosure"]},{text:"impl Debug for ExprUnsafe",synthetic:false,types:["syn::expr::ExprUnsafe"]},{text:"impl Debug for ExprBlock",synthetic:false,types:["syn::expr::ExprBlock"]},{text:"impl Debug for ExprAssign",synthetic:false,types:["syn::expr::ExprAssign"]},{text:"impl Debug for ExprAssignOp",synthetic:false,types:["syn::expr::ExprAssignOp"]},{text:"impl Debug for ExprField",synthetic:false,types:["syn::expr::ExprField"]},{text:"impl Debug for ExprIndex",synthetic:false,types:["syn::expr::ExprIndex"]},{text:"impl Debug for ExprRange",synthetic:false,types:["syn::expr::ExprRange"]},{text:"impl Debug for ExprPath",synthetic:false,types:["syn::expr::ExprPath"]},{text:"impl Debug for ExprReference",synthetic:false,types:["syn::expr::ExprReference"]},{text:"impl Debug for ExprBreak",synthetic:false,types:["syn::expr::ExprBreak"]},{text:"impl Debug for ExprContinue",synthetic:false,types:["syn::expr::ExprContinue"]},{text:"impl Debug for ExprReturn",synthetic:false,types:["syn::expr::ExprReturn"]},{text:"impl Debug for ExprMacro",synthetic:false,types:["syn::expr::ExprMacro"]},{text:"impl Debug for ExprStruct",synthetic:false,types:["syn::expr::ExprStruct"]},{text:"impl Debug for ExprRepeat",synthetic:false,types:["syn::expr::ExprRepeat"]},{text:"impl Debug for ExprParen",synthetic:false,types:["syn::expr::ExprParen"]},{text:"impl Debug for ExprGroup",synthetic:false,types:["syn::expr::ExprGroup"]},{text:"impl Debug for ExprTry",synthetic:false,types:["syn::expr::ExprTry"]},{text:"impl Debug for ExprCatch",synthetic:false,types:["syn::expr::ExprCatch"]},{text:"impl Debug for ExprYield",synthetic:false,types:["syn::expr::ExprYield"]},{text:"impl Debug for ExprVerbatim",synthetic:false,types:["syn::expr::ExprVerbatim"]},{text:"impl Debug for Member",synthetic:false,types:["syn::expr::Member"]},{text:"impl Debug for Index",synthetic:false,types:["syn::expr::Index"]},{text:"impl Debug for Generics",synthetic:false,types:["syn::generics::Generics"]},{text:"impl Debug for GenericParam",synthetic:false,types:["syn::generics::GenericParam"]},{text:"impl Debug for TypeParam",synthetic:false,types:["syn::generics::TypeParam"]},{text:"impl Debug for LifetimeDef",synthetic:false,types:["syn::generics::LifetimeDef"]},{text:"impl Debug for ConstParam",synthetic:false,types:["syn::generics::ConstParam"]},{text:"impl<'a> Debug for ImplGenerics<'a>",synthetic:false,types:["syn::generics::ImplGenerics"]},{text:"impl<'a> Debug for TypeGenerics<'a>",synthetic:false,types:["syn::generics::TypeGenerics"]},{text:"impl<'a> Debug for Turbofish<'a>",synthetic:false,types:["syn::generics::Turbofish"]},{text:"impl Debug for BoundLifetimes",synthetic:false,types:["syn::generics::BoundLifetimes"]},{text:"impl Debug for TypeParamBound",synthetic:false,types:["syn::generics::TypeParamBound"]},{text:"impl Debug for TraitBound",synthetic:false,types:["syn::generics::TraitBound"]},{text:"impl Debug for TraitBoundModifier",synthetic:false,types:["syn::generics::TraitBoundModifier"]},{text:"impl Debug for WhereClause",synthetic:false,types:["syn::generics::WhereClause"]},{text:"impl Debug for WherePredicate",synthetic:false,types:["syn::generics::WherePredicate"]},{text:"impl Debug for PredicateType",synthetic:false,types:["syn::generics::PredicateType"]},{text:"impl Debug for PredicateLifetime",synthetic:false,types:["syn::generics::PredicateLifetime"]},{text:"impl Debug for PredicateEq",synthetic:false,types:["syn::generics::PredicateEq"]},{text:"impl Debug for Lifetime",synthetic:false,types:["syn::lifetime::Lifetime"]},{text:"impl Debug for Lit",synthetic:false,types:["syn::lit::Lit"]},{text:"impl Debug for LitStr",synthetic:false,types:["syn::lit::LitStr"]},{text:"impl Debug for LitByteStr",synthetic:false,types:["syn::lit::LitByteStr"]},{text:"impl Debug for LitByte",synthetic:false,types:["syn::lit::LitByte"]},{text:"impl Debug for LitChar",synthetic:false,types:["syn::lit::LitChar"]},{text:"impl Debug for LitInt",synthetic:false,types:["syn::lit::LitInt"]},{text:"impl Debug for LitFloat",synthetic:false,types:["syn::lit::LitFloat"]},{text:"impl Debug for LitBool",synthetic:false,types:["syn::lit::LitBool"]},{text:"impl Debug for LitVerbatim",synthetic:false,types:["syn::lit::LitVerbatim"]},{text:"impl Debug for StrStyle",synthetic:false,types:["syn::lit::StrStyle"]},{text:"impl Debug for IntSuffix",synthetic:false,types:["syn::lit::IntSuffix"]},{text:"impl Debug for FloatSuffix",synthetic:false,types:["syn::lit::FloatSuffix"]},{text:"impl Debug for Macro",synthetic:false,types:["syn::mac::Macro"]},{text:"impl Debug for MacroDelimiter",synthetic:false,types:["syn::mac::MacroDelimiter"]},{text:"impl Debug for DeriveInput",synthetic:false,types:["syn::derive::DeriveInput"]},{text:"impl Debug for Data",synthetic:false,types:["syn::derive::Data"]},{text:"impl Debug for DataStruct",synthetic:false,types:["syn::derive::DataStruct"]},{text:"impl Debug for DataEnum",synthetic:false,types:["syn::derive::DataEnum"]},{text:"impl Debug for DataUnion",synthetic:false,types:["syn::derive::DataUnion"]},{text:"impl Debug for BinOp",synthetic:false,types:["syn::op::BinOp"]},{text:"impl Debug for UnOp",synthetic:false,types:["syn::op::UnOp"]},{text:"impl Debug for Type",synthetic:false,types:["syn::ty::Type"]},{text:"impl Debug for TypeSlice",synthetic:false,types:["syn::ty::TypeSlice"]},{text:"impl Debug for TypeArray",synthetic:false,types:["syn::ty::TypeArray"]},{text:"impl Debug for TypePtr",synthetic:false,types:["syn::ty::TypePtr"]},{text:"impl Debug for TypeReference",synthetic:false,types:["syn::ty::TypeReference"]},{text:"impl Debug for TypeBareFn",synthetic:false,types:["syn::ty::TypeBareFn"]},{text:"impl Debug for TypeNever",synthetic:false,types:["syn::ty::TypeNever"]},{text:"impl Debug for TypeTuple",synthetic:false,types:["syn::ty::TypeTuple"]},{text:"impl Debug for TypePath",synthetic:false,types:["syn::ty::TypePath"]},{text:"impl Debug for TypeTraitObject",synthetic:false,types:["syn::ty::TypeTraitObject"]},{text:"impl Debug for TypeImplTrait",synthetic:false,types:["syn::ty::TypeImplTrait"]},{text:"impl Debug for TypeParen",synthetic:false,types:["syn::ty::TypeParen"]},{text:"impl Debug for TypeGroup",synthetic:false,types:["syn::ty::TypeGroup"]},{text:"impl Debug for TypeInfer",synthetic:false,types:["syn::ty::TypeInfer"]},{text:"impl Debug for TypeMacro",synthetic:false,types:["syn::ty::TypeMacro"]},{text:"impl Debug for TypeVerbatim",synthetic:false,types:["syn::ty::TypeVerbatim"]},{text:"impl Debug for Abi",synthetic:false,types:["syn::ty::Abi"]},{text:"impl Debug for BareFnArg",synthetic:false,types:["syn::ty::BareFnArg"]},{text:"impl Debug for BareFnArgName",synthetic:false,types:["syn::ty::BareFnArgName"]},{text:"impl Debug for ReturnType",synthetic:false,types:["syn::ty::ReturnType"]},{text:"impl Debug for Path",synthetic:false,types:["syn::path::Path"]},{text:"impl<'a> Debug for PathTokens<'a>",synthetic:false,types:["syn::path::PathTokens"]},{text:"impl Debug for PathSegment",synthetic:false,types:["syn::path::PathSegment"]},{text:"impl Debug for PathArguments",synthetic:false,types:["syn::path::PathArguments"]},{text:"impl Debug for GenericArgument",synthetic:false,types:["syn::path::GenericArgument"]},{text:"impl Debug for AngleBracketedGenericArguments",synthetic:false,types:["syn::path::AngleBracketedGenericArguments"]},{text:"impl Debug for Binding",synthetic:false,types:["syn::path::Binding"]},{text:"impl Debug for ParenthesizedGenericArguments",synthetic:false,types:["syn::path::ParenthesizedGenericArguments"]},{text:"impl Debug for QSelf",synthetic:false,types:["syn::path::QSelf"]},{text:"impl<T: Debug, P: Debug> Debug for Punctuated<T, P>",synthetic:false,types:["syn::punctuated::Punctuated"]},{text:"impl Debug for ParseError",synthetic:false,types:["syn::error::ParseError"]},]; implementors["synstructure"] = [{text:"impl Debug for BindStyle",synthetic:false,types:["synstructure::BindStyle"]},{text:"impl<'a> Debug for BindingInfo<'a>",synthetic:false,types:["synstructure::BindingInfo"]},{text:"impl<'a> Debug for VariantAst<'a>",synthetic:false,types:["synstructure::VariantAst"]},{text:"impl<'a> Debug for VariantInfo<'a>",synthetic:false,types:["synstructure::VariantInfo"]},{text:"impl<'a> Debug for Structure<'a>",synthetic:false,types:["synstructure::Structure"]},]; if (window.register_implementors) { window.register_implementors(implementors); } else { window.pending_implementors = implementors; } })()