3 types derived from Queue
System.Private.CoreLib (1)
src\libraries\System.Private.CoreLib\src\System\Threading\Tasks\Task.cs (1)
6834private sealed class WhenEachState : Queue<Task>, IValueTaskSource, ITaskCompletionAction
System.Windows.Input.Manipulations (2)
System\Windows\Input\Manipulations\ManipulationSequence.cs (2)
1233private class HistoryQueue : Queue<ManipulationState> 1327private class SmoothingQueue : Queue<ManipulationState>
100 instantiations of Queue
Amg88xx (1)
Amg88xx.cs (1)
432var flagRegisters = new Queue<byte>();
Amg88xx.Tests (2)
I2cTestDevice.cs (2)
12public Queue<byte> DataToRead { get; } = new Queue<byte>(); 13public Queue<byte> DataWritten { get; } = new Queue<byte>();
Arduino (1)
FirmataDevice.cs (1)
95_dataQueue = new Queue<byte>(1024);
dotnet (2)
Installer\Windows\PipeStreamSetupLogger.cs (1)
20private readonly Queue<string> _messageQueue = new();
Telemetry\PersistenceChannel\FixedSizeQueue.cs (1)
13private readonly Queue<T> _queue = new();
dotnet-watch (1)
HotReload\HotReloadProfileReader.cs (1)
15var queue = new Queue<ProjectGraphNode>(projectGraph.EntryPointNodes);
illink (7)
Iot.Device.Bindings (5)
Amg88xx.cs (1)
432var flagRegisters = new Queue<byte>();
FirmataDevice.cs (1)
95_dataQueue = new Queue<byte>(1024);
NmeaUdpServer.cs (1)
196_data = new Queue<byte>();
SentenceCache.cs (2)
57_lastRouteSentences = new Queue<RoutePart>(); 58_lastSatelliteInfos = new Queue<SatellitesInView>();
Microsoft.AspNetCore.Components (2)
Rendering\RenderBatchBuilder.cs (2)
32public Queue<RenderQueueEntry> ComponentRenderQueue { get; } = new Queue<RenderQueueEntry>(); 33public Queue<int> ComponentDisposalQueue { get; } = new Queue<int>();
Microsoft.AspNetCore.Components.Endpoints (1)
FormMapping\Converters\CollectionAdapters\QueueBufferAdapter.cs (1)
8public static Queue<TElement> CreateBuffer() => new();
Microsoft.AspNetCore.Components.Endpoints.Tests (1)
Binding\FormDataMapperTests.cs (1)
769var expected = new Queue<int>(new[] { 10, 11, 12, 13, 14, 15, 16, 17, 18, 19 });
Microsoft.AspNetCore.Components.WebAssembly (1)
Hosting\WebAssemblyCallQueue.cs (1)
21private static readonly Queue<Action> _pendingWork = new();
Microsoft.AspNetCore.Components.WebView (1)
Services\WebViewRenderer.cs (1)
12private readonly Queue<UnacknowledgedRenderBatch> _unacknowledgedRenderBatches = new();
Microsoft.AspNetCore.Http.Extensions (1)
src\Components\Endpoints\src\FormMapping\Converters\CollectionAdapters\QueueBufferAdapter.cs (1)
8public static Queue<TElement> CreateBuffer() => new();
Microsoft.AspNetCore.Server.Kestrel.Core (1)
Internal\Http2\Http2FrameWriter.cs (1)
83private readonly Queue<Http2OutputProducer> _waitingForMoreConnectionWindow = new();
Microsoft.AspNetCore.Server.Kestrel.Microbenchmarks (1)
Mocks\MockHttpContextFactory.cs (1)
13private readonly Queue<DefaultHttpContext> _cache = new Queue<DefaultHttpContext>();
Microsoft.AspNetCore.TestHost (1)
TestWebSocket.cs (1)
256_messageQueue = new Queue<Message>();
Microsoft.Build (6)
BackEnd\Components\BuildRequestEngine\BuildRequestEngine.cs (1)
136_unsubmittedRequests = new Queue<PendingUnsubmittedBuildRequests>();
BackEnd\Components\RequestBuilder\TargetBuilder.cs (1)
782var targetsToCheckForAfterTargets = new Queue<string>();
BackEnd\Components\Scheduler\Scheduler.cs (2)
543_pendingRequestCoresCallbacks = new Queue<TaskCompletionSource<int>>(); 2628Queue<SchedulableRequest> blockingRequests = new Queue<SchedulableRequest>();
Graph\ProjectGraph.cs (2)
557var partialRoots = new Queue<ProjectGraphNode>(graphNodes.Count); 610var edgesToVisit = new Queue<ProjectGraphBuildRequest>();
Microsoft.Build.Engine (6)
Collections\DualQueue.cs (2)
36this.backingQueueA = new Queue<T>(); 37this.backingQueueB = new Queue<T>();
Engine\Node.cs (1)
44this.buildRequests = new Queue<BuildRequest>();
Engine\TaskWorkerThread.cs (2)
56this.workerThreadQueue = new Queue<TaskWorkerThread>(); 58this.workItemQueue = new Queue<TaskExecutionState>();
LocalProvider\LocalNodeProvider.cs (1)
84this.nodesToLaunch = new Queue<int>();
Microsoft.Cci.Extensions (2)
Extensions\CSharp\CSharpCciExtensions.cs (2)
139Queue<ITypeReference> typesToCheck = new Queue<ITypeReference>(); 175Queue<ITypeReference> typesToCheck = new Queue<ITypeReference>();
Microsoft.DotNet.ApiCompatibility (1)
Mapping\AssemblyMapper.cs (1)
55Queue<INamespaceSymbol> queue = new();
Microsoft.DotNet.AsmDiff (2)
AssemblySet.cs (2)
56var queue = new Queue<IAssemblyReference>(metadataHost.LoadedUnits.OfType<IAssemblyReference>()); 158var queue = new Queue<IAssemblyReference>(assemblies);
Microsoft.DotNet.Build.Tasks.Packaging (1)
CreateTrimDependencyGroups.cs (1)
85var newDependencyGroups = new Queue<TaskItemPackageDependencyGroup>();
Microsoft.DotNet.PackageValidation (2)
Package.cs (1)
228Queue<NuGetFramework> tfmQueue = new(AssemblyReferences.Keys);
Validators\CompatibleFrameworkInPackageValidator.cs (1)
39Queue<(NuGetFramework, IReadOnlyList<ContentItem>)> compileAssetsQueue = new();
Microsoft.Extensions.Logging.Console (1)
ConsoleLoggerProcessor.cs (1)
65_messageQueue = new Queue<LogMessageEntry>();
Microsoft.TemplateEngine.Cli (1)
Commands\Example.cs (1)
162Queue<CliCommand> probes = new();
MSBuild (1)
OutOfProcTaskHostNode.cs (1)
187_receivedPackets = new Queue<INodePacket>();
MSBuildTaskHost (1)
OutOfProcTaskHostNode.cs (1)
187_receivedPackets = new Queue<INodePacket>();
Nmea0183 (3)
NmeaUdpServer.cs (1)
196_data = new Queue<byte>();
SentenceCache.cs (2)
57_lastRouteSentences = new Queue<RoutePart>(); 58_lastSatelliteInfos = new Queue<SatellitesInView>();
PresentationCore (4)
System\Windows\Input\Stylus\Common\DynamicRenderer.cs (1)
1239Queue<StrokeInfo> _renderCompleteDRThreadStrokeInfoList = new Queue<StrokeInfo>();
System\Windows\Input\Stylus\Wisp\WispLogic.cs (1)
3666Queue<RawStylusInputReport> _queueStylusEvents = new Queue<RawStylusInputReport>();
System\Windows\Media\Animation\TimeManager.cs (1)
73_eventQueue = new Queue<WeakReference>();
System\Windows\Media\ChannelManager.cs (1)
156_freeSyncChannels = new Queue<DUCE.Channel>(3);
PresentationFramework (3)
MS\Internal\Data\DataBindEngine.cs (1)
721private Queue<DataBindOperation> _crossThreadQueue = new Queue<DataBindOperation>();
System\Windows\Controls\ItemContainerGenerator.cs (2)
492_recyclableContainers = new Queue<DependencyObject>(); 2805private Queue<DependencyObject> _recyclableContainers = new Queue<DependencyObject>();
System.Collections (2)
System\Collections\Generic\SortedSet.cs (1)
237var processQueue = new Queue<Node>();
System\Collections\Generic\SortedSet.TreeSubSet.cs (1)
253Queue<Node> processQueue = new Queue<Node>();
System.ComponentModel.Composition (2)
System\ComponentModel\Composition\ContractNameServices.cs (2)
128Queue<Type> genericTypeArguments = new Queue<Type>(type.GetGenericArguments()); 303Queue<Type> typeArguments = new Queue<Type>(types);
System.Composition.Hosting (1)
System\Composition\Hosting\Core\UpdateResult.cs (1)
22_remainingProviders = new Queue<ExportDescriptorProvider>(providers);
System.Diagnostics.Process (2)
System\Diagnostics\AsyncStreamReader.cs (1)
64_messageQueue = new Queue<string?>();
System\Diagnostics\Process.NonUap.cs (1)
44var descendantProcesses = new Queue<Process>();
System.Linq (3)
System\Linq\ElementAt.cs (1)
164Queue<TSource> queue = new();
System\Linq\Take.cs (2)
112queue = new Queue<TSource>(); 162queue = new Queue<TSource>();
System.Linq.Expressions (1)
System\Linq\Expressions\DebugViewWriter.cs (1)
402_lambdas ??= new Queue<LambdaExpression>();
System.Linq.Parallel (3)
System\Linq\Parallel\Channels\SynchronousChannel.cs (1)
48_queue = new Queue<T>();
System\Linq\Parallel\Merging\OrderPreservingPipeliningMergeHelper.cs (1)
444_mergeHelper._buffers[producer] = new Queue<Pair<TKey, TOutput>>(INITIAL_BUFFER_SIZE);
System\Linq\Parallel\Scheduling\OrderPreservingPipeliningSpoolingTask.cs (1)
164buffers[i] = new Queue<Pair<TKey, TOutput>>(OrderPreservingPipeliningMergeHelper<TOutput, TKey>.INITIAL_BUFFER_SIZE);
System.Private.CoreLib (2)
src\libraries\System.Private.CoreLib\src\System\IO\Enumeration\FileSystemEnumerator.Unix.cs (1)
150_pending ??= new Queue<(string Path, int RemainingDepth)>();
src\libraries\System.Private.CoreLib\src\System\SearchValues\Strings\Helpers\AhoCorasickBuilder.cs (1)
138var queue = new Queue<(char Char, int Index)>();
System.Private.DataContractSerialization (3)
src\libraries\Common\src\System\CodeDom\CodeTypeReference.cs (1)
148var q = new Queue<int>();
System\Runtime\Serialization\DataContract.cs (1)
1135Queue<Type> itemTypeQueue = new Queue<Type>();
System\Runtime\Serialization\ExtensionDataReader.cs (1)
507_deserializedDataNodes ??= new Queue<IDataNode>();
System.Private.Xml (2)
System\Xml\Schema\ContentValidator.cs (1)
1451var unmarked = new Queue<BitSet>();
System\Xml\Serialization\CodeGenerator.cs (1)
1592freeLocalQueue = new Queue<LocalBuilder>();
System.Runtime.Serialization.Formatters (1)
System\Runtime\Serialization\Formatters\Binary\BinaryObjectWriter.cs (1)
66_objectQueue = new Queue<object>();
System.Text.Json (2)
src\libraries\System.Text.Json\Common\JsonHelpers.cs (1)
102var childlessQueue = new Queue<int>(); // the queue of nodes without children or whose children have been visited
System\Text\Json\Serialization\JsonSerializer.Read.Stream.cs (1)
520CreateObject = static () => new Queue<T>(),
System.Text.Json.SourceGeneration (2)
JsonSourceGenerator.Parser.cs (1)
45private readonly Queue<TypeToGenerate> _typesToGenerate = new();
src\libraries\System.Text.Json\Common\JsonHelpers.cs (1)
102var childlessQueue = new Queue<int>(); // the queue of nodes without children or whose children have been visited
System.Text.RegularExpressions (1)
System\Text\RegularExpressions\Symbolic\SymbolicRegexMatcher.Explore.cs (1)
22Queue<MatchingState<TSet>> toExplore = new();
System.Threading.Tasks.Dataflow (3)
Blocks\BatchBlock.cs (1)
244private readonly Queue<T> _messages = new Queue<T>();
Blocks\BroadcastBlock.cs (1)
502private readonly Queue<TOutput> _messages = new Queue<TOutput>();
Blocks\JoinBlock.cs (1)
520if (dbo.Greedy) _messages = new Queue<T>();
System.Xaml (5)
System\Xaml\Context\NameFixupGraph.cs (1)
50_resolvedTokensPendingProcessing = new Queue<NameFixupToken>();
System\Xaml\Parser\NodeStreamSorter.cs (1)
101_buffer = new Queue<XamlNode>();
System\Xaml\Parser\XamlScanner.cs (1)
51_readNodesQueue = new Queue<XamlScannerNode>();
System\Xaml\XamlNodeQueue.cs (1)
29_nodeQueue = new Queue<XamlNode>();
System\Xaml\XamlObjectReader.cs (1)
2485pendingNameScopes = new Queue<NameScopeMarkupInfo>();
Vcnl4040.Tests (2)
I2cTestDevice.cs (2)
12public Queue<byte> DataToRead { get; } = new System.Collections.Generic.Queue<byte>(); 13public Queue<byte> DataWritten { get; } = new Queue<byte>();
176 references to Queue
Amg88xx (1)
Amg88xx.cs (1)
432var flagRegisters = new Queue<byte>();
Amg88xx.Tests (2)
I2cTestDevice.cs (2)
12public Queue<byte> DataToRead { get; } = new Queue<byte>(); 13public Queue<byte> DataWritten { get; } = new Queue<byte>();
Arduino (1)
FirmataDevice.cs (1)
52private Queue<byte> _dataQueue;
dotnet (2)
Installer\Windows\PipeStreamSetupLogger.cs (1)
20private readonly Queue<string> _messageQueue = new();
Telemetry\PersistenceChannel\FixedSizeQueue.cs (1)
13private readonly Queue<T> _queue = new();
dotnet-watch (1)
HotReload\HotReloadProfileReader.cs (1)
15var queue = new Queue<ProjectGraphNode>(projectGraph.EntryPointNodes);
illink (11)
Iot.Device.Bindings (5)
Amg88xx.cs (1)
432var flagRegisters = new Queue<byte>();
FirmataDevice.cs (1)
52private Queue<byte> _dataQueue;
NmeaUdpServer.cs (1)
181private readonly Queue<byte> _data;
SentenceCache.cs (2)
32private Queue<RoutePart> _lastRouteSentences; 34private Queue<SatellitesInView> _lastSatelliteInfos;
Microsoft.AspNetCore.Components (2)
Rendering\RenderBatchBuilder.cs (2)
32public Queue<RenderQueueEntry> ComponentRenderQueue { get; } = new Queue<RenderQueueEntry>(); 33public Queue<int> ComponentDisposalQueue { get; } = new Queue<int>();
Microsoft.AspNetCore.Components.Endpoints (11)
FormMapping\Converters\CollectionAdapters\QueueBufferAdapter.cs (7)
6internal sealed class QueueBufferAdapter<TElement> : ICollectionBufferAdapter<Queue<TElement>, Queue<TElement>, TElement> 8public static Queue<TElement> CreateBuffer() => new(); 10public static Queue<TElement> Add(ref Queue<TElement> buffer, TElement element) 16public static Queue<TElement> ToResult(Queue<TElement> buffer) => buffer;
FormMapping\Factories\Collections\TypedCollectionConverterFactory.cs (4)
46var _ when type == (typeof(Queue<TElement>)) => true, 133var _ when type.IsAssignableTo(typeof(Queue<TElement>)) => 134new CollectionConverter<Queue<TElement>, QueueBufferAdapter<TElement>, Queue<TElement>, TElement>(elementTypeConverter),
Microsoft.AspNetCore.Components.Endpoints.Tests (3)
Binding\FormDataMapperTests.cs (3)
769var expected = new Queue<int>(new[] { 10, 11, 12, 13, 14, 15, 16, 17, 18, 19 }); 770CanDeserialize_Collection<Queue<int>, Queue<int>, int>(expected);
Microsoft.AspNetCore.Components.WebAssembly (1)
Hosting\WebAssemblyCallQueue.cs (1)
21private static readonly Queue<Action> _pendingWork = new();
Microsoft.AspNetCore.Components.WebView (1)
Services\WebViewRenderer.cs (1)
12private readonly Queue<UnacknowledgedRenderBatch> _unacknowledgedRenderBatches = new();
Microsoft.AspNetCore.Http.Extensions (11)
src\Components\Endpoints\src\FormMapping\Converters\CollectionAdapters\QueueBufferAdapter.cs (7)
6internal sealed class QueueBufferAdapter<TElement> : ICollectionBufferAdapter<Queue<TElement>, Queue<TElement>, TElement> 8public static Queue<TElement> CreateBuffer() => new(); 10public static Queue<TElement> Add(ref Queue<TElement> buffer, TElement element) 16public static Queue<TElement> ToResult(Queue<TElement> buffer) => buffer;
src\Components\Endpoints\src\FormMapping\Factories\Collections\TypedCollectionConverterFactory.cs (4)
46var _ when type == (typeof(Queue<TElement>)) => true, 133var _ when type.IsAssignableTo(typeof(Queue<TElement>)) => 134new CollectionConverter<Queue<TElement>, QueueBufferAdapter<TElement>, Queue<TElement>, TElement>(elementTypeConverter),
Microsoft.AspNetCore.Server.Kestrel.Core (1)
Internal\Http2\Http2FrameWriter.cs (1)
83private readonly Queue<Http2OutputProducer> _waitingForMoreConnectionWindow = new();
Microsoft.AspNetCore.Server.Kestrel.Microbenchmarks (1)
Mocks\MockHttpContextFactory.cs (1)
13private readonly Queue<DefaultHttpContext> _cache = new Queue<DefaultHttpContext>();
Microsoft.AspNetCore.TestHost (1)
TestWebSocket.cs (1)
251private readonly Queue<Message> _messageQueue;
Microsoft.Build (6)
BackEnd\Components\BuildRequestEngine\BuildRequestEngine.cs (1)
76private readonly Queue<PendingUnsubmittedBuildRequests> _unsubmittedRequests;
BackEnd\Components\RequestBuilder\TargetBuilder.cs (1)
782var targetsToCheckForAfterTargets = new Queue<string>();
BackEnd\Components\Scheduler\Scheduler.cs (2)
114private Queue<TaskCompletionSource<int>> _pendingRequestCoresCallbacks; 2628Queue<SchedulableRequest> blockingRequests = new Queue<SchedulableRequest>();
Graph\ProjectGraph.cs (2)
557var partialRoots = new Queue<ProjectGraphNode>(graphNodes.Count); 610var edgesToVisit = new Queue<ProjectGraphBuildRequest>();
Microsoft.Build.Engine (14)
Collections\DualQueue.cs (8)
84Queue<T> readingQueue = backingQueueB; 206Queue<T> readingQueue = GetReadingQueue(); 240private Queue<T> GetReadingQueue() 242Queue<T> readingQueue = backingQueueB; 260Queue<T> postingQueue = queue; 306private Queue<T> queue; 311private Queue<T> backingQueueA; 316private Queue<T> backingQueueB;
Engine\Node.cs (1)
639private Queue<BuildRequest> buildRequests;
Engine\TaskWorkerThread.cs (4)
75Queue<TaskWorkerThread> workerThreadQueue, 77Queue<TaskExecutionState> workItemQueue, 604private Queue<TaskWorkerThread> workerThreadQueue; // Queue of idle worker thread ready to be activated 606private Queue<TaskExecutionState> workItemQueue; // Queue of workitems that need to be executed
LocalProvider\LocalNodeProvider.cs (1)
993private Queue<int> nodesToLaunch;
Microsoft.Cci.Extensions (2)
Extensions\CSharp\CSharpCciExtensions.cs (2)
139Queue<ITypeReference> typesToCheck = new Queue<ITypeReference>(); 175Queue<ITypeReference> typesToCheck = new Queue<ITypeReference>();
Microsoft.DotNet.ApiCompatibility (1)
Mapping\AssemblyMapper.cs (1)
55Queue<INamespaceSymbol> queue = new();
Microsoft.DotNet.AsmDiff (2)
AssemblySet.cs (2)
56var queue = new Queue<IAssemblyReference>(metadataHost.LoadedUnits.OfType<IAssemblyReference>()); 158var queue = new Queue<IAssemblyReference>(assemblies);
Microsoft.DotNet.Build.Tasks.Packaging (1)
CreateTrimDependencyGroups.cs (1)
85var newDependencyGroups = new Queue<TaskItemPackageDependencyGroup>();
Microsoft.DotNet.PackageValidation (2)
Package.cs (1)
228Queue<NuGetFramework> tfmQueue = new(AssemblyReferences.Keys);
Validators\CompatibleFrameworkInPackageValidator.cs (1)
39Queue<(NuGetFramework, IReadOnlyList<ContentItem>)> compileAssetsQueue = new();
Microsoft.Extensions.Logging.Console (1)
ConsoleLoggerProcessor.cs (1)
17private readonly Queue<LogMessageEntry> _messageQueue;
Microsoft.TemplateEngine.Cli (1)
Commands\Example.cs (1)
162Queue<CliCommand> probes = new();
MSBuild (1)
OutOfProcTaskHostNode.cs (1)
86private Queue<INodePacket> _receivedPackets;
MSBuildTaskHost (1)
OutOfProcTaskHostNode.cs (1)
86private Queue<INodePacket> _receivedPackets;
mscorlib (1)
mscorlib.cs (1)
57[assembly:System.Runtime.CompilerServices.TypeForwardedTo(typeof(System.Collections.Generic.Queue<>))]
netstandard (1)
netstandard.cs (1)
129[assembly: System.Runtime.CompilerServices.TypeForwardedTo(typeof(System.Collections.Generic.Queue<>))]
Nmea0183 (3)
NmeaUdpServer.cs (1)
181private readonly Queue<byte> _data;
SentenceCache.cs (2)
32private Queue<RoutePart> _lastRouteSentences; 34private Queue<SatellitesInView> _lastSatelliteInfos;
PresentationCore (4)
System\Windows\Input\Stylus\Common\DynamicRenderer.cs (1)
1239Queue<StrokeInfo> _renderCompleteDRThreadStrokeInfoList = new Queue<StrokeInfo>();
System\Windows\Input\Stylus\Wisp\WispLogic.cs (1)
3666Queue<RawStylusInputReport> _queueStylusEvents = new Queue<RawStylusInputReport>();
System\Windows\Media\Animation\TimeManager.cs (1)
917private Queue<WeakReference> _eventQueue;
System\Windows\Media\ChannelManager.cs (1)
261private Queue<DUCE.Channel> _freeSyncChannels;
PresentationFramework (2)
MS\Internal\Data\DataBindEngine.cs (1)
721private Queue<DataBindOperation> _crossThreadQueue = new Queue<DataBindOperation>();
System\Windows\Controls\ItemContainerGenerator.cs (1)
2805private Queue<DependencyObject> _recyclableContainers = new Queue<DependencyObject>();
System (1)
src\libraries\shims\System\ref\System.cs (1)
137[assembly: System.Runtime.CompilerServices.TypeForwardedTo(typeof(System.Collections.Generic.Queue<>))]
System.Collections (3)
artifacts\obj\System.Collections\Debug\net9.0\System.Collections.Forwards.cs (1)
9[assembly: System.Runtime.CompilerServices.TypeForwardedTo(typeof(System.Collections.Generic.Queue<>))]
System\Collections\Generic\SortedSet.cs (1)
237var processQueue = new Queue<Node>();
System\Collections\Generic\SortedSet.TreeSubSet.cs (1)
253Queue<Node> processQueue = new Queue<Node>();
System.ComponentModel.Composition (5)
System\ComponentModel\Composition\ContractNameServices.cs (5)
128Queue<Type> genericTypeArguments = new Queue<Type>(type.GetGenericArguments()); 219private static void WriteGenericType(StringBuilder typeName, Type type, bool isDefinition, Queue<Type> genericTypeArguments, bool formatGenericName) 241private static void WriteGenericTypeName(StringBuilder typeName, Type type, bool isDefinition, Queue<Type> genericTypeArguments, bool formatGenericName) 256private static void WriteTypeArgumentsString(StringBuilder typeName, int argumentsCount, bool isDefinition, Queue<Type> genericTypeArguments, bool formatGenericName) 303Queue<Type> typeArguments = new Queue<Type>(types);
System.Composition.Hosting (1)
System\Composition\Hosting\Core\UpdateResult.cs (1)
16private readonly Queue<ExportDescriptorProvider> _remainingProviders;
System.Diagnostics.Process (2)
System\Diagnostics\AsyncStreamReader.cs (1)
37private readonly Queue<string?> _messageQueue;
System\Diagnostics\Process.NonUap.cs (1)
44var descendantProcesses = new Queue<Process>();
System.Linq (2)
System\Linq\ElementAt.cs (1)
164Queue<TSource> queue = new();
System\Linq\Take.cs (1)
100Queue<TSource> queue;
System.Linq.Expressions (1)
System\Linq\Expressions\DebugViewWriter.cs (1)
37private Queue<LambdaExpression>? _lambdas;
System.Linq.Parallel (10)
System\Linq\Parallel\Channels\SynchronousChannel.cs (1)
27private Queue<T>? _queue;
System\Linq\Parallel\Merging\OrderPreservingPipeliningMergeHelper.cs (6)
59private readonly Queue<Pair<TKey, TOutput>>[] _buffers; 132_buffers = new Queue<Pair<TKey, TOutput>>[partitionCount]; 239private readonly Queue<Pair<TKey, TOutput>>?[] _privateBuffer; 256_privateBuffer = new Queue<Pair<TKey, TOutput>>[partitionCount]; 392Queue<Pair<TKey, TOutput>> buffer = _mergeHelper._buffers[producer]; 462var privateChunk = _privateBuffer[producer];
System\Linq\Parallel\Scheduling\OrderPreservingPipeliningSpoolingTask.cs (3)
33private readonly Queue<Pair<TKey, TOutput>>[] _buffers; // The buffer for the results 62Queue<Pair<TKey, TOutput>>[] buffers, 150Queue<Pair<TKey, TOutput>>[] buffers, object[] bufferLocks,
System.Private.CoreLib (8)
src\libraries\System.Private.CoreLib\src\System\Collections\Generic\Queue.cs (3)
363/// Sets the capacity of a <see cref="Queue{T}"/> object to the specified number of entries. 424private readonly Queue<T> _q; 429internal Enumerator(Queue<T> q)
src\libraries\System.Private.CoreLib\src\System\Collections\Generic\QueueDebugView.cs (2)
10private readonly Queue<T> _queue; 12public QueueDebugView(Queue<T> queue)
src\libraries\System.Private.CoreLib\src\System\IO\Enumeration\FileSystemEnumerator.Unix.cs (1)
25private Queue<(string Path, int RemainingDepth)>? _pending;
src\libraries\System.Private.CoreLib\src\System\SearchValues\Strings\Helpers\AhoCorasickBuilder.cs (1)
138var queue = new Queue<(char Char, int Index)>();
src\libraries\System.Private.CoreLib\src\System\SearchValues\Strings\Helpers\AhoCorasickNode.cs (1)
81public readonly void AddChildrenToQueue(Queue<(char Char, int Index)> queue)
System.Private.DataContractSerialization (3)
src\libraries\Common\src\System\CodeDom\CodeTypeReference.cs (1)
148var q = new Queue<int>();
System\Runtime\Serialization\DataContract.cs (1)
1135Queue<Type> itemTypeQueue = new Queue<Type>();
System\Runtime\Serialization\ExtensionDataReader.cs (1)
46private Queue<IDataNode>? _deserializedDataNodes;
System.Private.Xml (6)
System\Xml\Schema\ContentValidator.cs (1)
1451var unmarked = new Queue<BitSet>();
System\Xml\Serialization\CodeGenerator.cs (5)
40private Dictionary<(Type, string), Queue<LocalBuilder>>? _freeLocals; 93_freeLocals = new Dictionary<(Type, string), Queue<LocalBuilder>>(); 223Queue<LocalBuilder>? freeLocalQueue; 1578public void AddToFreeLocals(Dictionary<(Type, string), Queue<LocalBuilder>> freeLocals) 1583Queue<LocalBuilder>? freeLocalQueue;
System.Runtime.Serialization.Formatters (1)
System\Runtime\Serialization\Formatters\Binary\BinaryObjectWriter.cs (1)
14private Queue<object>? _objectQueue;
System.Text.Json (14)
src\libraries\System.Text.Json\Common\JsonHelpers.cs (1)
102var childlessQueue = new Queue<int>(); // the queue of nodes without children or whose children have been visited
System\Text\Json\Serialization\Converters\Collection\IEnumerableConverterFactory.cs (1)
123else if ((actualTypeToConvert = typeToConvert.GetCompatibleGenericBaseClass(typeof(Queue<>))) != null)
System\Text\Json\Serialization\Converters\Collection\QueueOfTConverter.cs (1)
10where TCollection : Queue<TElement>
System\Text\Json\Serialization\JsonSerializer.Read.Stream.cs (8)
472JsonTypeInfo<Queue<T>> queueTypeInfo = jsonTypeInfo._asyncEnumerableQueueTypeInfo is { } cachedQueueTypeInfo 473? (JsonTypeInfo<Queue<T>>)cachedQueueTypeInfo 478static async IAsyncEnumerable<T> CreateAsyncEnumerable(Stream utf8Json, JsonTypeInfo<Queue<T>> queueTypeInfo, [EnumeratorCancellation] CancellationToken cancellationToken) 500var queue = (Queue<T>)returnValue!; 515static JsonTypeInfo<Queue<T>> CreateQueueTypeInfo(JsonTypeInfo<T> jsonTypeInfo) 517var queueConverter = new QueueOfTConverter<Queue<T>, T>(); 518var queueTypeInfo = new JsonTypeInfo<Queue<T>>(queueConverter, jsonTypeInfo.Options)
System\Text\Json\Serialization\Metadata\JsonMetadataServices.Collections.cs (3)
257/// Creates serialization metadata for types assignable to <see cref="Queue{T}"/>. 268where TCollection : Queue<TElement> 293/// Creates serialization metadata for types assignable to <see cref="Queue{T}"/>.
System.Text.Json.SourceGeneration (3)
Helpers\KnownTypeSymbols.cs (1)
58public INamedTypeSymbol? QueueOfTType => GetOrResolveType(typeof(Queue<>), ref _QueueOfTType);
JsonSourceGenerator.Parser.cs (1)
45private readonly Queue<TypeToGenerate> _typesToGenerate = new();
src\libraries\System.Text.Json\Common\JsonHelpers.cs (1)
102var childlessQueue = new Queue<int>(); // the queue of nodes without children or whose children have been visited
System.Text.RegularExpressions (4)
System\Text\RegularExpressions\Symbolic\SymbolicRegexMatcher.Explore.cs (4)
22Queue<MatchingState<TSet>> toExplore = new(); 65static (int nfaId, (SymbolicRegexMatcher<TSet> Matcher, HashSet<MatchingState<TSet>> Seen, Queue<MatchingState<TSet>> ToExplore) args) => 92static void EnqueueAll(MatchingState<TSet>[] states, HashSet<MatchingState<TSet>> seen, Queue<MatchingState<TSet>> toExplore) 100static void EnqueueIfUnseen(MatchingState<TSet> state, HashSet<MatchingState<TSet>> seen, Queue<MatchingState<TSet>> queue)
System.Threading.Tasks.Dataflow (3)
Blocks\BatchBlock.cs (1)
244private readonly Queue<T> _messages = new Queue<T>();
Blocks\BroadcastBlock.cs (1)
502private readonly Queue<TOutput> _messages = new Queue<TOutput>();
Blocks\JoinBlock.cs (1)
493private readonly Queue<T>? _messages;
System.Windows.Input.Manipulations (3)
System\Windows\Input\Manipulations\ManipulationSequence.cs (3)
1058private static float GetVelocity(Queue<ManipulationState> queue, PropertyAccessor accessor) 1075private static float CalculateWeightedMovingAverage(Queue<ManipulationState> queue, PropertyAccessor accessor) 1137private static float CalculateMovingAverage(Queue<ManipulationState> queue, PropertyAccessor accessor, float defaultValue)
System.Xaml (6)
System\Xaml\Context\NameFixupGraph.cs (1)
32Queue<NameFixupToken> _resolvedTokensPendingProcessing;
System\Xaml\Parser\NodeStreamSorter.cs (1)
23Queue<XamlNode> _buffer;
System\Xaml\Parser\XamlScanner.cs (1)
38Queue<XamlScannerNode> _readNodesQueue;
System\Xaml\XamlNodeQueue.cs (1)
19Queue<XamlNode> _nodeQueue;
System\Xaml\XamlObjectReader.cs (2)
2474Queue<NameScopeMarkupInfo> pendingNameScopes; 2522public Queue<NameScopeMarkupInfo> PendingNameScopes
Vcnl4040.Tests (2)
I2cTestDevice.cs (2)
12public Queue<byte> DataToRead { get; } = new System.Collections.Generic.Queue<byte>(); 13public Queue<byte> DataWritten { get; } = new Queue<byte>();