swc_common::sync

Trait Send

1.0.0 · source
pub unsafe auto trait Send { }
Expand description

Types that can be transferred across thread boundaries.

This trait is automatically implemented when the compiler determines it’s appropriate.

An example of a non-Send type is the reference-counting pointer rc::Rc. If two threads attempt to clone Rcs that point to the same reference-counted value, they might try to update the reference count at the same time, which is undefined behavior because Rc doesn’t use atomic operations. Its cousin sync::Arc does use atomic operations (incurring some overhead) and thus is Send.

See the Nomicon and the Sync trait for more details.

Implementors§

1.0.0 · source§

impl !Send for Arguments<'_>

source§

impl !Send for LocalWaker

1.26.0 · source§

impl !Send for Args

1.26.0 · source§

impl !Send for ArgsOs

1.6.0 · source§

impl Send for alloc::string::Drain<'_>

source§

impl Send for core::ffi::c_str::Bytes<'_>

1.36.0 · source§

impl Send for Waker

§

impl Send for Arena

§

impl Send for ArenaHandle<'_>

§

impl Send for Atom

Immutable, so it’s safe to be shared between threads

§

impl Send for Bytes

§

impl Send for BytesMut

§

impl Send for Collector

§

impl Send for Parker

§

impl Send for Unparker

1.44.0 · source§

impl<'a> Send for IoSlice<'a>

1.44.0 · source§

impl<'a> Send for IoSliceMut<'a>

§

impl<'a, 'b, K, Q, V, S, A> Send for OccupiedEntryRef<'a, 'b, K, Q, V, S, A>
where K: Send, Q: Sync + ?Sized, V: Send, S: Send, A: Send + Allocator,

§

impl<'a, R, T> Send for MappedMutexGuard<'a, R, T>
where R: RawMutex + 'a, T: Send + 'a + ?Sized, <R as RawMutex>::GuardMarker: Send,

§

impl<'a, R, T> Send for MappedRwLockReadGuard<'a, R, T>
where R: RawRwLock + 'a, T: Sync + 'a + ?Sized, <R as RawRwLock>::GuardMarker: Send,

§

impl<'a, R, T> Send for MappedRwLockWriteGuard<'a, R, T>
where R: RawRwLock + 'a, T: Send + 'a + ?Sized, <R as RawRwLock>::GuardMarker: Send,

§

impl<'a, T> Send for ArcBorrow<'a, T>
where T: Sync + Send + ?Sized,

§

impl<'a, T> Send for Drain<'a, T>
where T: Send + Array,

§

impl<'a, T> Send for ZeroVec<'a, T>
where T: AsULE, <T as AsULE>::ULE: Send + Sync,

§

impl<'a, T, O> Send for Iter<'a, T, O>
where T: BitStore, O: BitOrder, &'a mut BitSlice<T, O>: Send,

§

impl<'a, T, O> Send for IterMut<'a, T, O>
where T: BitStore, O: BitOrder, &'a mut BitSlice<T, O>: Send,

§

impl<A> Send for SmallVec<A>
where A: Array, <A as Array>::Item: Send,

§

impl<A, B> Send for ArcUnion<A, B>
where A: Sync + Send, B: Send + Sync,

§

impl<C> Send for CartableOptionPointer<C>
where C: Sync + CartablePointerLike,

source§

impl<Dyn> Send for core::ptr::metadata::DynMetadata<Dyn>
where Dyn: ?Sized,

§

impl<Dyn> Send for DynMetadata<Dyn>
where Dyn: ?Sized,

§

impl<H, T> Send for ThinArc<H, T>
where H: Sync + Send, T: Sync + Send,

§

impl<K, V> Send for IterMut<'_, K, V>
where K: Send, V: Send,

§

impl<K, V> Send for IterMut<'_, K, V>
where K: Send, V: Send,

§

impl<K, V, S, A> Send for OccupiedEntry<'_, K, V, S, A>
where K: Send, V: Send, S: Send, A: Send + Allocator,

§

impl<K, V, S, A> Send for OccupiedEntry<'_, K, V, S, A>
where K: Send, V: Send, S: Send, A: Send + Allocator,

§

impl<K, V, S, A> Send for RawOccupiedEntryMut<'_, K, V, S, A>
where K: Send, V: Send, S: Send, A: Send + Allocator,

§

impl<M, T, O> Send for BitRef<'_, M, T, O>
where M: Mutability, T: BitStore + Sync, O: BitOrder,

§

impl<R, G> Send for RawReentrantMutex<R, G>
where R: RawMutex + Send, G: GetThreadId + Send,

§

impl<R, G, T> Send for ReentrantMutex<R, G, T>
where R: RawMutex + Send, G: GetThreadId + Send, T: Send + ?Sized,

§

impl<R, T> Send for Mutex<R, T>
where R: RawMutex + Send, T: Send + ?Sized,

§

impl<R, T> Send for RwLock<R, T>
where R: RawRwLock + Send, T: Send + ?Sized,

1.0.0 · source§

impl<T> !Send for *const T
where T: ?Sized,

1.0.0 · source§

impl<T> !Send for *mut T
where T: ?Sized,

1.25.0 · source§

impl<T> !Send for NonNull<T>
where T: ?Sized,

NonNull pointers are not Send because the data they reference may be aliased.

source§

impl<T> !Send for std::sync::mutex::MappedMutexGuard<'_, T>
where T: ?Sized,

1.0.0 · source§

impl<T> !Send for MutexGuard<'_, T>
where T: ?Sized,

source§

impl<T> !Send for ReentrantLockGuard<'_, T>
where T: ?Sized,

source§

impl<T> !Send for std::sync::rwlock::MappedRwLockReadGuard<'_, T>
where T: ?Sized,

source§

impl<T> !Send for std::sync::rwlock::MappedRwLockWriteGuard<'_, T>
where T: ?Sized,

1.0.0 · source§

impl<T> !Send for RwLockReadGuard<'_, T>
where T: ?Sized,

1.0.0 · source§

impl<T> !Send for RwLockWriteGuard<'_, T>
where T: ?Sized,

1.0.0 · source§

impl<T> Send for &T
where T: Sync + ?Sized,

source§

impl<T> Send for ThinBox<T>
where T: Send + ?Sized,

ThinBox<T> is Send if T is Send because the data is owned.

1.0.0 · source§

impl<T> Send for alloc::collections::linked_list::Iter<'_, T>
where T: Sync,

1.0.0 · source§

impl<T> Send for alloc::collections::linked_list::IterMut<'_, T>
where T: Send,

1.0.0 · source§

impl<T> Send for Cell<T>
where T: Send + ?Sized,

1.0.0 · source§

impl<T> Send for RefCell<T>
where T: Send + ?Sized,

1.28.0 · source§

impl<T> Send for NonZero<T>

1.31.0 · source§

impl<T> Send for ChunksExactMut<'_, T>
where T: Send,

1.0.0 · source§

impl<T> Send for ChunksMut<'_, T>
where T: Send,

1.0.0 · source§

impl<T> Send for core::slice::iter::Iter<'_, T>
where T: Sync,

1.0.0 · source§

impl<T> Send for core::slice::iter::IterMut<'_, T>
where T: Send,

1.31.0 · source§

impl<T> Send for RChunksExactMut<'_, T>
where T: Send,

1.31.0 · source§

impl<T> Send for RChunksMut<'_, T>
where T: Send,

1.0.0 · source§

impl<T> Send for AtomicPtr<T>

source§

impl<T> Send for std::sync::mpmc::Receiver<T>
where T: Send,

source§

impl<T> Send for std::sync::mpmc::Sender<T>
where T: Send,

1.0.0 · source§

impl<T> Send for std::sync::mpsc::Receiver<T>
where T: Send,

1.0.0 · source§

impl<T> Send for std::sync::mpsc::Sender<T>
where T: Send,

1.0.0 · source§

impl<T> Send for SyncSender<T>
where T: Send,

1.0.0 · source§

impl<T> Send for std::sync::mutex::Mutex<T>
where T: Send + ?Sized,

1.70.0 · source§

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

source§

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

1.0.0 · source§

impl<T> Send for std::sync::rwlock::RwLock<T>
where T: Send + ?Sized,

1.29.0 · source§

impl<T> Send for JoinHandle<T>

§

impl<T> Send for Arc<T>
where T: Sync + Send + ?Sized,

§

impl<T> Send for Atomic<T>
where T: Pointable + Send + Sync + ?Sized,

§

impl<T> Send for AtomicCell<T>
where T: Send,

§

impl<T> Send for BitSpanError<T>
where T: BitStore,

§

impl<T> Send for Bucket<T>

§

impl<T> Send for CachePadded<T>
where T: Send,

§

impl<T> Send for Injector<T>
where T: Send,

§

impl<T> Send for MisalignError<T>

§

impl<T> Send for OffsetArc<T>
where T: Sync + Send,

§

impl<T> Send for OutBuf<'_, T>
where T: Send,

§

impl<T> Send for OutRef<'_, T>
where T: Send,

§

impl<T> Send for ScopedJoinHandle<'_, T>

§

impl<T> Send for SerVec<T>
where T: Send,

§

impl<T> Send for ShardedLock<T>
where T: Send + ?Sized,

§

impl<T> Send for Stealer<T>
where T: Send,

§

impl<T> Send for UniqueArc<T>
where T: Send + ?Sized,

§

impl<T> Send for Worker<T>
where T: Send,

1.0.0 · source§

impl<T, A> !Send for Rc<T, A>
where A: Allocator, T: ?Sized,

1.4.0 · source§

impl<T, A> !Send for alloc::rc::Weak<T, A>
where A: Allocator, T: ?Sized,

source§

impl<T, A> Send for Cursor<'_, T, A>
where T: Sync, A: Allocator + Sync,

source§

impl<T, A> Send for CursorMut<'_, T, A>
where T: Send, A: Allocator + Send,

1.0.0 · source§

impl<T, A> Send for LinkedList<T, A>
where T: Send, A: Allocator + Send,

1.6.0 · source§

impl<T, A> Send for alloc::collections::vec_deque::drain::Drain<'_, T, A>
where T: Send, A: Allocator + Send,

1.4.0 · source§

impl<T, A> Send for alloc::sync::Weak<T, A>
where T: Sync + Send + ?Sized, A: Allocator + Send,

1.6.0 · source§

impl<T, A> Send for alloc::vec::drain::Drain<'_, T, A>
where T: Send, A: Send + Allocator,

1.0.0 · source§

impl<T, A> Send for alloc::vec::into_iter::IntoIter<T, A>
where T: Send, A: Allocator + Send,

1.0.0 · source§

impl<T, A> Send for swc_common::sync::Lrc<T, A>
where T: Sync + Send + ?Sized, A: Allocator + Send,

§

impl<T, A> Send for Box<T, A>
where A: Allocator + Send, T: Send + ?Sized,

§

impl<T, A> Send for Drain<'_, T, A>
where T: Send, A: Send + Allocator,

§

impl<T, A> Send for IntoIter<T, A>
where T: Send, A: Allocator + Send,

§

impl<T, A> Send for OccupiedEntry<'_, T, A>
where T: Send, A: Send + Allocator,

§

impl<T, A> Send for OccupiedEntry<'_, T, A>
where T: Send, A: Send + Allocator,

§

impl<T, A> Send for RawDrain<'_, T, A>
where A: Allocator + Send, T: Send,

§

impl<T, A> Send for RawIntoIter<T, A>
where A: Allocator + Send, T: Send,

§

impl<T, A> Send for RawTable<T, A>
where A: Allocator + Send, T: Send,

§

impl<T, O> Send for BitBox<T, O>
where T: BitStore, O: BitOrder,

§

impl<T, O> Send for BitSlice<T, O>
where T: BitStore + Sync, O: BitOrder,

§Bit-Slice Thread Safety

This allows bit-slice references to be moved across thread boundaries only when the underlying T element can tolerate concurrency.

All BitSlice references, shared or exclusive, are only threadsafe if the T element type is Send, because any given bit-slice reference may only have partial control of a memory element that is also being shared by a bit-slice reference on another thread. As such, this is never implemented for Cell<U>, but always implemented for AtomicU and U for a given unsigned integer type U.

Atomic integers safely handle concurrent writes, cells do not allow concurrency at all, so the only missing piece is &mut BitSlice<_, U: Unsigned>. This is handled by the aliasing system that the mutable splitters employ: a mutable reference to an unsynchronized bit-slice can only cross threads when no other handle is able to exist to the elements it governs. Splitting a mutable bit-slice causes the split halves to change over to either atomics or cells, so concurrency is either safe or impossible.

§

impl<T, O> Send for BitVec<T, O>
where T: BitStore, O: BitOrder,

§

impl<T, O> Send for Drain<'_, T, O>
where T: BitStore, O: BitOrder, &'a mut BitSlice<T, O>: for<'a> Send,

§

impl<T, O> Send for IntoIter<T, O>
where T: BitStore + Sync, O: BitOrder,

§

impl<T, const N: usize> Send for InlineVec<T, N>
where T: Send,

§

impl<const A: usize> Send for AlignedVec<A>

Auto implementors§

§

impl !Send for SingleThreadedComments

§

impl Send for ArchivedCommentKind

§

impl Send for CommentKind

§

impl Send for CommentKindResolver

§

impl Send for ColorConfig

§

impl Send for Destination

§

impl Send for Applicability

§

impl Send for ApplicabilityResolver

§

impl Send for ArchivedApplicability

§

impl Send for ArchivedLevel

§

impl Send for DiagnosticId

§

impl Send for Level

§

impl Send for LevelResolver

§

impl Send for Style

§

impl Send for TransformPluginMetadataContextKind

§

impl Send for ArchivedPluginError

§

impl Send for PluginError

§

impl Send for PluginErrorResolver

§

impl Send for ArchivedFileName

§

impl Send for ArchivedNonNarrowChar

§

impl Send for ArchivedSourceMapLookupError

§

impl Send for ArchivedSpanLinesError

§

impl Send for ArchivedSpanSnippetError

§

impl Send for FileName

§

impl Send for FileNameResolver

§

impl Send for NonNarrowChar

§

impl Send for NonNarrowCharResolver

§

impl Send for SourceMapLookupError

§

impl Send for SourceMapLookupErrorResolver

§

impl Send for SpanLinesError

§

impl Send for SpanLinesErrorResolver

§

impl Send for SpanSnippetError

§

impl Send for SpanSnippetErrorResolver

§

impl Send for core::fmt::Alignment

§

impl Send for ArchivedComment

§

impl Send for Comment

§

impl Send for CommentResolver

§

impl Send for NoopComments

§

impl Send for EmitterWriter

§

impl Send for ArchivedCodeSuggestion

§

impl Send for ArchivedSubstitution

§

impl Send for ArchivedSubstitutionPart

§

impl Send for CodeSuggestion

§

impl Send for CodeSuggestionResolver

§

impl Send for Diagnostic

§

impl Send for DiagnosticStyledString

§

impl Send for ExplicitBug

§

impl Send for FatalError

§

impl Send for FatalErrorMarker

§

impl Send for Handler

§

impl Send for HandlerFlags

§

impl Send for Message

§

impl Send for SubDiagnostic

§

impl Send for Substitution

§

impl Send for SubstitutionPart

§

impl Send for SubstitutionPartResolver

§

impl Send for SubstitutionResolver

§

impl Send for ArchivedMutableMarkContext

§

impl Send for ArchivedSyntaxContext

§

impl Send for Mark

§

impl Send for MutableMarkContext

§

impl Send for MutableMarkContextResolver

§

impl Send for SyntaxContext

§

impl Send for SyntaxContextResolver

§

impl Send for ArchivedPluginCorePkgDiagnostics

§

impl Send for PluginCorePkgDiagnostics

§

impl Send for PluginCorePkgDiagnosticsResolver

§

impl Send for TransformPluginMetadataContext

§

impl Send for PluginSerializedBytes

§

impl Send for Type

§

impl Send for ArchivedBytePos

§

impl Send for ArchivedCharPos

§

impl Send for ArchivedDistinctSources

§

impl Send for ArchivedFilePos

§

impl Send for ArchivedLineInfo

§

impl Send for ArchivedMalformedSourceMapPositions

§

impl Send for ArchivedMultiByteChar

§

impl Send for ArchivedMultiSpan

§

impl Send for ArchivedPartialFileLines

§

impl Send for ArchivedPartialLoc

§

impl Send for ArchivedPrimarySpanLabel

§

impl Send for ArchivedSourceFile

§

impl Send for ArchivedSourceFileAnalysis

§

impl Send for ArchivedSourceFileAndBytePos

§

impl Send for ArchivedSpan

§

impl Send for BytePos

§

impl Send for BytePosResolver

§

impl Send for ByteToCharPosState

§

impl Send for CharPos

§

impl Send for CharPosResolver

§

impl Send for DefaultSourceMapGenConfig

§

impl Send for DistinctSources

§

impl Send for DistinctSourcesResolver

§

impl Send for EncodePathBuf

§

impl Send for EncodeUrl

§

impl Send for FileLines

§

impl Send for FilePathMapping

§

impl Send for FilePos

§

impl Send for FilePosResolver

§

impl Send for Globals

§

impl Send for LineCol

§

impl Send for LineInfo

§

impl Send for LineInfoResolver

§

impl Send for Loc

§

impl Send for LocWithOpt

§

impl Send for MalformedSourceMapPositions

§

impl Send for MalformedSourceMapPositionsResolver

§

impl Send for MultiByteChar

§

impl Send for MultiByteCharResolver

§

impl Send for MultiSpan

§

impl Send for MultiSpanResolver

§

impl Send for PartialFileLines

§

impl Send for PartialFileLinesResolver

§

impl Send for PartialLoc

§

impl Send for PartialLocResolver

§

impl Send for PrimarySpanLabel

§

impl Send for PrimarySpanLabelResolver

§

impl Send for RealFileLoader

§

impl Send for SourceFile

§

impl Send for SourceFileAnalysis

§

impl Send for SourceFileAnalysisResolver

§

impl Send for SourceFileAndBytePos

§

impl Send for SourceFileAndBytePosResolver

§

impl Send for SourceFileAndLine

§

impl Send for SourceFileResolver

§

impl Send for SourceMap

§

impl Send for Span

§

impl Send for SpanLabel

§

impl Send for SpanResolver

§

impl Send for StableSourceFileId

§

impl Send for Error

§

impl Send for core::ptr::alignment::Alignment

§

impl Send for AdjacentlyTaggedEnumVariant

§

impl Send for TagContentOtherField

§

impl Send for TagContentOtherFieldVisitor

§

impl Send for TagOrContentField

§

impl Send for TagOrContentFieldVisitor

§

impl<'a> !Send for Formatter<'a>

§

impl<'a> Send for WritableDst<'a>

§

impl<'a> Send for DiagnosticBuilder<'a>

§

impl<'a> Send for StringInput<'a>

§

impl<'a> Send for InternallyTaggedUnitVisitor<'a>

§

impl<'a> Send for UntaggedUnitVisitor<'a>

§

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

§

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

§

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

§

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

§

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

§

impl<'a, 'de, E> Send for ContentRefDeserializer<'a, 'de, E>
where E: Send,

§

impl<'a, 'de, E> Send for FlatMapDeserializer<'a, 'de, E>
where E: Send,

§

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

§

impl<'a, K> Send for AstKindPathGuard<'a, K>
where K: Send,

§

impl<'a, K> Send for AstKindPathIndexGuard<'a, K>
where K: Send,

§

impl<'a, M> Send for FlatMapSerializeMap<'a, M>
where M: Send,

§

impl<'a, M> Send for FlatMapSerializeStruct<'a, M>
where M: Send,

§

impl<'a, M> Send for FlatMapSerializeStructVariantAsMapValue<'a, M>
where M: Send,

§

impl<'a, M> Send for FlatMapSerializeTupleVariantAsMapValue<'a, M>
where M: Send,

§

impl<'a, M> Send for FlatMapSerializer<'a, M>
where M: Send,

§

impl<'a, N> Send for AstNodePathGuard<'a, N>
where N: Send, <N as NodeRef>::ParentKind: Send,

§

impl<'a, N> Send for AstNodePathIndexGuard<'a, N>
where N: Send, <N as NodeRef>::ParentKind: Send,

§

impl<'a, T> Send for InPlaceSeed<'a, T>
where T: Send,

§

impl<'de> Send for Content<'de>

§

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

§

impl<'de, E> Send for ContentDeserializer<'de, E>
where E: Send,

§

impl<'de, E> Send for EnumDeserializer<'de, E>
where E: Send,

§

impl<'de, T> Send for Borrowed<'de, T>
where T: Sync + ?Sized,

§

impl<B, F, I> Send for ChainWith<B, F, I>
where B: Send, F: Send, I: Send,

§

impl<F> Send for FromFn<F>
where F: Send,

§

impl<F> Send for AdjacentlyTaggedEnumVariantSeed<F>
where F: Send,

§

impl<F> Send for AdjacentlyTaggedEnumVariantVisitor<F>
where F: Send,

§

impl<It> Send for swc_common::iter::Iter<It>
where It: Send, <It as Iterator>::Item: Send,

§

impl<K> Send for AstKindPath<K>
where K: Send,

§

impl<L, R> Send for Either<L, R>
where L: Send, R: Send,

§

impl<N> Send for AstNodePath<N>
where N: Send, <N as NodeRef>::ParentKind: Send,

§

impl<T> Send for Option<T>
where T: Send,

§

impl<T> Send for CacheCell<T>
where T: Send,

§

impl<T> Send for ArchivedVersionedSerializable<T>
where <T as Archive>::Archived: Send,

§

impl<T> Send for VersionedSerializable<T>
where T: Send,

§

impl<T> Send for VersionedSerializableResolver<T>
where <T as Archive>::Resolver: Send,

§

impl<T> Send for Node<T>
where T: Send,

§

impl<T> Send for PhantomData<T>
where T: Send + ?Sized,

§

impl<T> Send for Lock<T>
where T: Send,

§

impl<T> Send for LockCell<T>
where T: Send,

§

impl<T> Send for OnceCell<T>
where T: Send,

§

impl<T> Send for swc_common::sync::RwLock<T>
where T: Send,

§

impl<T> Send for CannotSerializeVariant<T>
where T: Send,

§

impl<T> Send for TaggedContentVisitor<T>
where T: Send,

§

impl<T, A> Send for Vec<T, A>
where A: Send, T: Send,

§

impl<T, E> Send for Result<T, E>
where T: Send, E: Send,

§

impl<T, F> Send for Lazy<T, F>
where T: Send, F: Send,

§

impl<V> Send for All<V>
where V: Send,

§

impl<V> Send for Optional<V>
where V: Send,

§

impl<V> Send for Repeat<V>
where V: Send,

impl<T> Send for ScopedKey<T>

impl !Send for ModuleRecord

impl Send for Cmd

impl Send for EsCommand

impl Send for JsRuntime

impl Send for NextCommand

impl Send for ReduceMode

impl Send for Output

impl Send for EnsureSize

impl Send for FileSize

impl Send for InputFile

impl Send for AppArgs

impl Send for Normalizer

impl Send for ChildGuard

impl !Send for Folder

impl Send for FieldType

impl Send for TraitKind

impl Send for Variant

impl Send for CliArgs

impl<'a> Send for Generator<'a>

impl Send for Expr

impl Send for PropOrParam

impl Send for Tag

impl Send for Type

impl Send for AbstractTag

impl Send for AccessTag

impl Send for AliasTag

impl Send for AllType

impl Send for AsyncTag

impl Send for AugmentsTag

impl Send for AuthorTag

impl Send for BorrowsTag

impl Send for CallbackTag

impl Send for ClassTag

impl Send for ConstTag

impl Send for DefaultTag

impl Send for EnumTag

impl Send for ExampleTag

impl Send for ExportsTag

impl Send for ExternalTag

impl Send for FileTag

impl Send for FunctionTag

impl Send for IgnoreTag

impl Send for InnerTag

impl Send for InstanceTag

impl Send for JsDoc

impl Send for KindTag

impl Send for LendsTag

impl Send for LicenseTag

impl Send for ListensTag

impl Send for MemberOfTag

impl Send for MemberTag

impl Send for MixesTag

impl Send for MixinTag

impl Send for ModuleTag

impl Send for NamePath

impl Send for NameTag

impl Send for OverrideTag

impl Send for PackageTag

impl Send for ParenType

impl Send for PrivateTag

impl Send for PropertyTag

impl Send for PublicTag

impl Send for ReadonlyTag

impl Send for RequiresTag

impl Send for ReturnTag

impl Send for SeeTag

impl Send for SinceTag

impl Send for StaticTag

impl Send for SummaryTag

impl Send for TagItem

impl Send for TemplateTag

impl Send for Text

impl Send for ThisTag

impl Send for ThrowTag

impl Send for TodoTag

impl Send for TutorialTag

impl Send for TypeDefTag

impl Send for TypeExpr

impl Send for TypeLit

impl Send for TypeTag

impl Send for TypedefTag

impl Send for UnionType

impl Send for UnknownTag

impl Send for UnknownType

impl Send for VersionTag

impl Send for YieldTag

impl<'i> Send for Input<'i>

impl Send for Query

impl Send for Targets

impl Send for EsModules

impl Send for Version

impl<'a, T> Send for BrowserDataMutIter<'a, T>
where T: Send,

impl<'a, T> Send for BrowserDataRefIter<'a, T>
where T: Sync,

impl<T> Send for BrowserData<T>
where T: Send,

impl Send for ConfigFile

impl Send for ErrorFormat

impl Send for FileMatcher

impl Send for Rc

impl Send for RootMode

impl Send for Config

impl Send for ErrorConfig

impl Send for JscConfig

impl Send for Options

impl Send for Compiler

impl<'a, 'b, P> Send for PassBuilder<'a, 'b, P>
where P: Send,

impl<P> !Send for BuiltInput<P>

impl Send for Arena

impl Send for Scoped

impl Send for Atom

impl Send for AtomStore

impl Send for UnsafeAtom

impl Send for BundleKind

impl Send for ModuleType

impl Send for Bundle

impl Send for Config

impl Send for ModuleData

impl Send for ModuleId

impl<'a, L, R> Send for Bundler<'a, L, R>

impl Send for CachedRegex

impl<'a> !Send for PrintArgs<'a>

impl Send for IsModule

impl<T> Send for BoolOr<T>
where T: Send,

impl<T> Send for BoolOrDataConfig<T>
where T: Send,

impl<T> Send for MergingOption<T>
where T: Send,

impl<const DEFAULT: bool> Send for BoolConfig<DEFAULT>

impl Send for AlphaValue

impl Send for AnPlusB

impl Send for AtRuleName

impl Send for BinOp

impl Send for CalcValue

impl Send for Color

impl Send for Dimension

impl Send for FamilyName

impl Send for Hue

impl Send for ImportHref

impl Send for MediaType

impl Send for Namespace

impl Send for NumberType

impl Send for Rule

impl Send for SizeFeature

impl Send for StyleBlock

impl Send for Token

impl Send for UrlModifier

impl Send for UrlValue

impl Send for Angle

impl Send for AtRule

impl Send for CalcProduct

impl Send for CalcSum

impl Send for Combinator

impl Send for CustomIdent

impl Send for DashedIdent

impl Send for Declaration

impl Send for Delimiter

impl Send for Flex

impl Send for Frequency

impl Send for Function

impl Send for HexColor

impl Send for IdSelector

impl Send for Ident

impl Send for Integer

impl Send for LayerName

impl Send for Length

impl Send for MediaAnd

impl Send for MediaNot

impl Send for MediaOr

impl Send for MediaQuery

impl Send for Number

impl Send for Percentage

impl Send for Ratio

impl Send for Resolution

impl Send for ScopeRange

impl Send for SimpleBlock

impl Send for Str

impl Send for Stylesheet

impl Send for SupportsAnd

impl Send for SupportsNot

impl Send for SupportsOr

impl Send for Time

impl Send for Url

impl Send for UrlKeyValue

impl Send for UrlValueRaw

impl Send for WqName

impl Send for IndentType

impl Send for LineFeed

impl<'a, W> Send for BasicCssWriter<'a, W>
where W: Send,

impl<W> Send for CodeGenerator<W>
where W: Send,

impl Send for Compiler

impl Send for Config

impl Send for Features

impl Send for LintConfig

impl<'a> Send for LintParams<'a>

impl Send for ErrorKind

impl Send for Error

impl Send for LexerState

impl Send for State

impl Send for Tokens

impl<'a> !Send for Input<'a>

impl<'a> Send for InputType<'a>

impl<'a, I> !Send for Lexer<'a, I>

impl<I> Send for Parser<I>
where I: Send,

impl Send for Options

impl Send for NamedColor

impl<'a> Send for FunctionNameReplacer<'a>

impl<'a> Send for IdentReplacer<'a>

impl Send for AngleField

impl Send for AtRuleField

impl Send for BinOpField

impl Send for ColorField

impl Send for FlexField

impl Send for HueField

impl Send for IdentField

impl Send for LengthField

impl Send for NumberField

impl Send for RatioField

impl Send for RuleField

impl Send for StrField

impl Send for TimeField

impl Send for TokenField

impl Send for UrlField

impl Send for WqNameField

impl<'ast> Send for NodeRef<'ast>

impl<'ast> Send for AstParentNodeRef<'ast>

impl Send for AssignOp

impl Send for BinaryOp

impl Send for Callee

impl Send for ClassMember

impl Send for Decl

impl Send for DefaultDecl

impl Send for EsVersion

impl Send for Expr

impl Send for ForHead

impl Send for ImportPhase

impl Send for JSXAttrName

impl Send for JSXExpr

impl Send for JSXObject

impl Send for Key

impl Send for Lit

impl Send for MemberProp

impl Send for MethodKind

impl Send for ModuleDecl

impl Send for ModuleItem

impl Send for Pat

impl Send for Program

impl Send for Prop

impl Send for PropName

impl Send for Stmt

impl Send for SuperProp

impl Send for TsFnParam

impl Send for TsLit

impl Send for TsModuleRef

impl Send for TsType

impl Send for UnaryOp

impl Send for UpdateOp

impl Send for VarDeclKind

impl Send for ArchivedTpl

impl Send for ArrayLit

impl Send for ArrayPat

impl Send for ArrowExpr

impl Send for AssignExpr

impl Send for AssignPat

impl Send for AssignProp

impl Send for AwaitExpr

impl Send for BigInt

impl Send for BinExpr

impl Send for BlockStmt

impl Send for Bool

impl Send for BreakStmt

impl Send for CallExpr

impl Send for CatchClause

impl Send for Class

impl Send for ClassDecl

impl Send for ClassExpr

impl Send for ClassMethod

impl Send for ClassProp

impl Send for CondExpr

impl Send for Constructor

impl Send for Decorator

impl Send for DoWhileStmt

impl Send for EmptyStmt

impl Send for ExportAll

impl Send for ExportDecl

impl Send for ExprStmt

impl Send for FnDecl

impl Send for FnExpr

impl Send for ForInStmt

impl Send for ForOfStmt

impl Send for ForStmt

impl Send for Function

impl Send for GetterProp

impl Send for Ident

impl Send for IdentName

impl Send for IfStmt

impl Send for Import

impl Send for ImportDecl

impl Send for ImportWith

impl Send for Invalid

impl Send for JSXAttr

impl Send for JSXElement

impl Send for JSXFragment

impl Send for JSXText

impl Send for LabeledStmt

impl Send for ListFormat

impl Send for MemberExpr

impl Send for MethodProp

impl Send for Module

impl Send for NamedExport

impl Send for NewExpr

impl Send for Null

impl Send for Number

impl Send for ObjectLit

impl Send for ObjectPat

impl Send for OptCall

impl Send for Param

impl Send for ParenExpr

impl Send for PrivateName

impl Send for PrivateProp

impl Send for Regex

impl Send for RestPat

impl Send for ReturnStmt

impl Send for Script

impl Send for SeqExpr

impl Send for SetterProp

impl Send for StaticBlock

impl Send for Str

impl Send for Super

impl Send for SwitchCase

impl Send for SwitchStmt

impl Send for TaggedTpl

impl Send for ThisExpr

impl Send for ThrowStmt

impl Send for Tpl

impl Send for TplElement

impl Send for TplResolver

impl Send for TryStmt

impl Send for TsArrayType

impl Send for TsAsExpr

impl Send for TsEnumDecl

impl Send for TsFnType

impl Send for TsInferType

impl Send for TsLitType

impl Send for TsParamProp

impl Send for TsRestType

impl Send for TsThisType

impl Send for TsTupleType

impl Send for TsTypeAnn

impl Send for TsTypeLit

impl Send for TsTypeParam

impl Send for TsTypeQuery

impl Send for TsTypeRef

impl Send for TsUnionType

impl Send for UnaryExpr

impl Send for UpdateExpr

impl Send for UsingDecl

impl Send for VarDecl

impl Send for WhileStmt

impl Send for WithStmt

impl Send for YieldExpr

impl Send for Config

impl<'a, W> Send for JsWriter<'a, W>
where W: Send,

impl<'a, W, S> !Send for Emitter<'a, W, S>

impl Send for Config

impl Send for Config

impl Send for Config

impl Send for Config

impl Send for Config

impl Send for Config

impl Send for Config

impl Send for Config

impl Send for Config

impl Send for Config

impl Send for Config

impl Send for Config

impl Send for Config

impl Send for Config

impl Send for Config

impl Send for Config

impl Send for Config

impl Send for Config

impl Send for Config

impl Send for Config

impl Send for ErrorKind

impl Send for JscTarget

impl Send for TokenType

impl Send for TokenValue

impl Send for Error

impl Send for Syntax

impl Send for Token

impl<'a> !Send for Lexer<'a>

impl<'a> !Send for Parser<'a>

impl !Send for TokensInput

impl Send for Syntax

impl Send for SyntaxError

impl Send for BinOpToken

impl Send for IdentKind

impl Send for IdentLike

impl Send for Keyword

impl Send for KnownIdent

impl Send for Token

impl Send for TokenKind

impl Send for Word

impl Send for WordKind

impl Send for Error

impl Send for Context

impl Send for EsSyntax

impl Send for TsSyntax

impl<'a> !Send for Lexer<'a>

impl<I> !Send for Capturing<I>

impl<I> Send for Buffer<I>
where I: Send,

impl Send for LintConfig

impl<'a> Send for LintParams<'a>

impl<T> Send for RuleConfig<T>
where T: Send,

impl Send for TargetEnv

impl Send for Resolution

impl<R> Send for CachingResolver<R>

impl<R> Send for TsConfigResolver<R>

impl Send for EvalResult

impl Send for Evaluator

impl Send for Timings

impl<I> Send for Parser<I>
where I: Send,

impl Send for Feature

impl Send for Mode

impl Send for Config

impl Send for DeclKind

impl Send for IdentType

impl Send for ScopeKind

impl Send for Assumptions

impl Send for FeatureFlag

impl Send for HelperData

impl Send for Helpers

impl Send for Config

impl<'a> Send for SuperFieldAccessFolder<'a>

impl !Send for Resolver

impl !Send for Cjs

impl !Send for Umd

impl Send for Lazy

impl Send for Config

impl Send for Config

impl Send for Config

impl Send for Config

impl Send for Config

impl<C> !Send for Amd<C>

impl<R> Send for NodeImportResolver<R>

impl Send for Config

impl Send for Config

impl Send for Config

impl Send for Config

impl Send for AssertValid

impl Send for Config

impl Send for Runtime

impl Send for Options

impl !Send for PassContext

impl<'a> !Send for BabelLikeFixtureTest<'a>

impl<'a> !Send for Tester<'a>

impl Send for Config

impl Send for TsxConfig

impl Send for AccessKind

impl Send for ScopeKind

impl Send for AliasConfig

impl Send for Ctx

impl Send for Marks

impl<S> Send for UsageAnalyzer<S>
where S: Send, <S as Storage>::ScopeData: Send,

impl Send for Purity

impl Send for Type

impl Send for JsNumber

impl Send for DropSpan

impl Send for ExprCtx

impl Send for Hoister

impl Send for ThisVisitor

impl<'a> Send for IdentRefFinder<'a>

impl<'a> Send for IdentRenamer<'a>

impl<'a> Send for IdentReplacer<'a>

impl<'a> Send for IdentUsageFinder<'a>

impl<'a> Send for Remapper<'a>

impl<'a, I> Send for VarCollector<'a, I>

impl<'a, Node> Send for NodeIgnoringSpan<'a, Node>
where <Node as ToOwned>::Owned: Send, Node: Sync,

impl<F> Send for BindingIdentifierVisitor<F>
where F: Send,

impl<I> Send for BindingCollector<I>

impl<I> Send for DestructuringFinder<I>

impl<N, R> Send for FnWrapperResult<N, R>
where N: Send, R: Send,

impl<T> Send for Value<T>
where T: Send,

impl<T> Send for FunctionWrapper<T>
where T: Send,

impl<T> Send for RefRewriter<T>
where T: Send,

impl Send for BigIntField

impl Send for BoolField

impl Send for CalleeField

impl Send for ClassField

impl Send for DeclField

impl Send for ExprField

impl Send for FnDeclField

impl Send for FnExprField

impl Send for IdentField

impl Send for IfStmtField

impl Send for ImportField

impl Send for KeyField

impl Send for LitField

impl Send for ModuleField

impl Send for NullField

impl Send for NumberField

impl Send for ParamField

impl Send for PatField

impl Send for PropField

impl Send for RegexField

impl Send for ScriptField

impl Send for StmtField

impl Send for StrField

impl Send for SuperField

impl Send for TplField

impl Send for TsLitField

impl Send for TsTypeField

impl<'ast> Send for NodeRef<'ast>

impl<'ast> Send for AstParentNodeRef<'ast>

impl<V> Send for FoldPass<V>
where V: Send,

impl<V> Send for VisitMutPass<V>
where V: Send,

impl<V> Send for VisitPass<V>
where V: Send,

impl Send for BigIntField

impl Send for BoolField

impl Send for CalleeField

impl Send for ClassField

impl Send for DeclField

impl Send for ExprField

impl Send for FnDeclField

impl Send for FnExprField

impl Send for IdentField

impl Send for IfStmtField

impl Send for ImportField

impl Send for KeyField

impl Send for LitField

impl Send for ModuleField

impl Send for NullField

impl Send for NumberField

impl Send for ParamField

impl Send for PatField

impl Send for PropField

impl Send for RegexField

impl Send for ScriptField

impl Send for StmtField

impl Send for StrField

impl Send for SuperField

impl Send for TplField

impl<'ast> Send for NodeRef<'ast>

impl<'ast> Send for AstParentNodeRef<'ast>

impl Send for HandlerOpts

impl<T> Send for TWithDiagnosticArray<T>
where T: Send,

impl Send for Access

impl Send for Arg

impl Send for ArrayExprEl

impl Send for Binary

impl Send for Block

impl Send for BlockParent

impl Send for Callee

impl Send for Class

impl Send for ClassBodyEl

impl Send for ClassImpl

impl Send for Comment

impl Send for CommentType

impl Send for Conditional

impl Send for Declaration

impl Send for EnumBody

impl Send for EnumMember

impl Send for ExportKind

impl Send for Expression

impl Send for Flow

impl Send for FlowType

impl Send for For

impl Send for ForStmtInit

impl Send for ForStmtLeft

impl Send for Function

impl Send for IdOrRest

impl Send for IdOrString

impl Send for Immutable

impl Send for ImportKind

impl Send for ImportPhase

impl Send for JSX

impl Send for JSXAttrName

impl Send for JSXAttrVal

impl Send for LVal

impl Send for Literal

impl Send for Loop

impl Send for Method

impl Send for ModuleKind

impl Send for ObjectKey

impl Send for Param

impl Send for Pattern

impl Send for PatternLike

impl Send for PlusOrMinus

impl Send for Private

impl Send for Property

impl Send for Pureish

impl Send for Scopable

impl Send for SrcType

impl Send for Statement

impl Send for TSBaseType

impl Send for TSType

impl Send for TupleExprEl

impl Send for UnaryExprOp

impl Send for UnaryLike

impl Send for While

impl Send for Flavor

impl Send for BaseComment

impl Send for BaseNode

impl Send for CatchClause

impl Send for ClassBody

impl Send for ClassMethod

impl Send for Decorator

impl Send for Directive

impl Send for File

impl Send for Identifier

impl Send for IfStatement

impl Send for Import

impl Send for JSXElement

impl Send for JSXFragment

impl Send for JSXText

impl Send for LineCol

impl Send for Loc

impl Send for Noop

impl Send for NullLiteral

impl Send for OpaqueType

impl Send for Placeholder

impl Send for PrivateName

impl Send for Program

impl Send for RestElement

impl Send for StaticBlock

impl Send for Super

impl Send for SwitchCase

impl Send for TSArrayType

impl Send for TSInferType

impl Send for TSRestType

impl Send for TSThisType

impl Send for TSTupleType

impl Send for TSTypeQuery

impl Send for TSUnionType

impl Send for TypeAlias

impl Send for Variance

impl Send for Context

impl Send for Context

impl Send for ErrorCode

impl Send for Mode

impl Send for Options

impl Send for TsError

impl<G> Send for GraphAnalyzer<G>
where G: Send, <G as DepGraph>::ModuleId: Send,

impl<G> Send for GraphResult<G>
where G: Send, <G as DepGraph>::ModuleId: Send,

impl Send for Child

impl Send for Namespace

impl Send for Raw

impl Send for Token

impl Send for Attribute

impl Send for Comment

impl Send for Document

impl Send for Element

impl Send for Text

impl Send for IndentType

impl Send for LineFeed

impl<'a> Send for CodegenConfig<'a>

impl<'a, W> Send for CodeGenerator<'a, W>
where W: Send,

impl<'a, W> Send for BasicHtmlWriter<'a, W>
where W: Send,

impl Send for CssOptions

impl Send for JsOptions

impl Send for JsonOptions

impl<CO> Send for MinifyCssOption<CO>
where CO: Send,

impl<CO> Send for MinifyOptions<CO>
where CO: Send,

impl Send for ErrorKind

impl Send for State

impl Send for Error

impl<I> !Send for Lexer<I>

impl<I> !Send for Parser<I>

impl Send for Element

impl Send for Entity

impl Send for ChildField

impl Send for RawField

impl Send for TextField

impl Send for TokenField

impl<'ast> Send for NodeRef<'ast>

impl<'ast> Send for AstParentNodeRef<'ast>

impl<'a> !Send for BindedField<'a>

impl<'a> !Send for Binder<'a>

impl<'a> !Send for VariantBinder<'a>

impl<'a> !Send for Derive<'a>

impl Send for EntryConfig

impl Send for Mode

impl Send for SwcLoader

impl Send for AliasConfig

impl Send for Config

impl<T, Ret> Send for JsCallback<T, Ret>
where T: Send, Ret: Send,

impl Send for SwcComments

impl<T> Send for PseudoScopedKey<T>
where T: Send,

impl Send for Cmd

impl Send for CliArgs

impl<'a> Send for Bump<'a>

impl !Send for Timer

impl Send for DtsIssue

impl Send for SourceRange

impl Send for FastDts

impl Send for Child

impl Send for Namespace

impl Send for Token

impl Send for Attribute

impl Send for Comment

impl Send for Document

impl Send for Element

impl Send for Text

impl Send for IndentType

impl Send for LineFeed

impl<'a> Send for CodegenConfig<'a>

impl<'a, W> Send for CodeGenerator<'a, W>
where W: Send,

impl<'a, W> Send for BasicXmlWriter<'a, W>
where W: Send,

impl Send for ErrorKind

impl Send for State

impl Send for Phase

impl Send for Error

impl<I> !Send for Parser<I>

impl<I> Send for Lexer<I>
where I: Send,

impl Send for ChildField

impl Send for TextField

impl Send for TokenField

impl<'ast> Send for NodeRef<'ast>

impl<'ast> Send for AstParentNodeRef<'ast>

impl Send for Tester

impl<'a> Send for DebugUsingDisplay<'a>

impl<R> Send for TestOutput<R>
where R: Send,

impl Send for Cmd

impl Send for Cmd

impl Send for Cmd

impl Send for Inner

impl Send for Inner

impl Send for Inner

impl Send for BenchCmd

impl Send for CleanCmd

impl Send for MinifierCmd

impl Send for EsCmd

impl Send for CoreVerCmd

impl Send for ReduceCmd

impl Send for GitCmd

impl Send for NightlyCmd

impl Send for NpmCmd

impl Send for CliArgs

impl Send for LockfilePkg