3 types derived from ConcurrentQueue
System.Private.CoreLib (1)
src\libraries\Common\src\System\Collections\Concurrent\MultiProducerMultiConsumerQueue.cs (1)
14internal sealed class MultiProducerMultiConsumerQueue<T> : ConcurrentQueue<T>, IProducerConsumerQueue<T>
System.Threading.Channels (1)
src\libraries\Common\src\System\Collections\Concurrent\MultiProducerMultiConsumerQueue.cs (1)
14internal sealed class MultiProducerMultiConsumerQueue<T> : ConcurrentQueue<T>, IProducerConsumerQueue<T>
System.Threading.Tasks.Dataflow (1)
src\libraries\Common\src\System\Collections\Concurrent\MultiProducerMultiConsumerQueue.cs (1)
14internal sealed class MultiProducerMultiConsumerQueue<T> : ConcurrentQueue<T>, IProducerConsumerQueue<T>
142 instantiations of ConcurrentQueue
Aspire.Confluent.Kafka (3)
ConfluentKafkaMetrics.cs (3)
22public ConcurrentQueue<Measurement<long>> ReplyQueueMeasurements { get; } = new ConcurrentQueue<Measurement<long>>(); 23public ConcurrentQueue<Measurement<long>> MessageCountMeasurements { get; } = new ConcurrentQueue<Measurement<long>>(); 24public ConcurrentQueue<Measurement<long>> MessageSizeMeasurements { get; } = new ConcurrentQueue<Measurement<long>>();
Aspire.Dashboard.Components.Tests (4)
tests\Shared\Logging\TestSink.cs (4)
20_scopes = new ConcurrentQueue<BeginScopeContext>(); 21_writes = new ConcurrentQueue<WriteContext>(); 28public IProducerConsumerCollection<BeginScopeContext> Scopes { get => _scopes; set => _scopes = new ConcurrentQueue<BeginScopeContext>(value); } 30public IProducerConsumerCollection<WriteContext> Writes { get => _writes; set => _writes = new ConcurrentQueue<WriteContext>(value); }
Aspire.Dashboard.Tests (4)
tests\Shared\Logging\TestSink.cs (4)
20_scopes = new ConcurrentQueue<BeginScopeContext>(); 21_writes = new ConcurrentQueue<WriteContext>(); 28public IProducerConsumerCollection<BeginScopeContext> Scopes { get => _scopes; set => _scopes = new ConcurrentQueue<BeginScopeContext>(value); } 30public IProducerConsumerCollection<WriteContext> Writes { get => _writes; set => _writes = new ConcurrentQueue<WriteContext>(value); }
Aspire.Hosting.Analyzers (1)
AppHostAnalyzer.cs (1)
34var concurrentQueue = new ConcurrentQueue<ConcurrentDictionary<ModelNameOperation, byte>>();
Aspire.Hosting.Testing.Tests (4)
tests\Shared\Logging\TestSink.cs (4)
20_scopes = new ConcurrentQueue<BeginScopeContext>(); 21_writes = new ConcurrentQueue<WriteContext>(); 28public IProducerConsumerCollection<BeginScopeContext> Scopes { get => _scopes; set => _scopes = new ConcurrentQueue<BeginScopeContext>(value); } 30public IProducerConsumerCollection<WriteContext> Writes { get => _writes; set => _writes = new ConcurrentQueue<WriteContext>(value); }
Aspire.Hosting.Tests (4)
tests\Shared\Logging\TestSink.cs (4)
20_scopes = new ConcurrentQueue<BeginScopeContext>(); 21_writes = new ConcurrentQueue<WriteContext>(); 28public IProducerConsumerCollection<BeginScopeContext> Scopes { get => _scopes; set => _scopes = new ConcurrentQueue<BeginScopeContext>(value); } 30public IProducerConsumerCollection<WriteContext> Writes { get => _writes; set => _writes = new ConcurrentQueue<WriteContext>(value); }
Aspire.Playground.Tests (4)
tests\Shared\Logging\TestSink.cs (4)
20_scopes = new ConcurrentQueue<BeginScopeContext>(); 21_writes = new ConcurrentQueue<WriteContext>(); 28public IProducerConsumerCollection<BeginScopeContext> Scopes { get => _scopes; set => _scopes = new ConcurrentQueue<BeginScopeContext>(value); } 30public IProducerConsumerCollection<WriteContext> Writes { get => _writes; set => _writes = new ConcurrentQueue<WriteContext>(value); }
dotnet-svcutil-lib (1)
FrameworkFork\System.ServiceModel\Internals\System\Runtime\Diagnostics\EtwDiagnosticTrace.cs (1)
453private static readonly ConcurrentQueue<StringBuilder> s_freeStringBuilders = new ConcurrentQueue<StringBuilder>();
Infrastructure.Common (1)
xunit\WcfTestCase.cs (1)
51ConcurrentQueue<EventWrittenEventArgs> events = new ConcurrentQueue<EventWrittenEventArgs>();
InMemory.FunctionalTests (4)
EventSourceTests.cs (1)
423private readonly ConcurrentQueue<EventSnapshot> _events = new ConcurrentQueue<EventSnapshot>();
src\Servers\Kestrel\shared\test\Http3\Http3InMemory.cs (1)
77internal readonly ConcurrentQueue<TestStreamContext> _streamContextPool = new ConcurrentQueue<TestStreamContext>();
src\Servers\Kestrel\shared\test\TestApplicationErrorLogger.cs (2)
29public ConcurrentQueue<LogMessage> Messages { get; } = new ConcurrentQueue<LogMessage>(); 31public ConcurrentQueue<object> Scopes { get; } = new ConcurrentQueue<object>();
Interop.FunctionalTests (1)
src\Shared\Buffers.MemoryPool\PinnedBlockMemoryPool.cs (1)
44private readonly ConcurrentQueue<MemoryPoolBlock> _blocks = new ConcurrentQueue<MemoryPoolBlock>();
Microsoft.AspNetCore.App.Analyzers (2)
Mvc\MvcAnalyzer.cs (1)
40var concurrentQueue = new ConcurrentQueue<(List<ActionRoute> ActionRoutes, List<AttributeInfo> AuthorizeAttributes)>();
RouteHandlers\RouteHandlerAnalyzer.cs (1)
47var concurrentQueue = new ConcurrentQueue<ConcurrentDictionary<MapOperation, byte>>();
Microsoft.AspNetCore.Components.Endpoints (1)
FormMapping\Converters\CollectionAdapters\ConcurrentQueueBufferAdapter.cs (1)
10public static ConcurrentQueue<TElement> CreateBuffer() => new();
Microsoft.AspNetCore.Components.Endpoints.Tests (1)
Binding\FormDataMapperTests.cs (1)
793var expected = new ConcurrentQueue<int>(new[] { 10, 11, 12, 13, 14, 15, 16, 17, 18, 19 });
Microsoft.AspNetCore.Components.Server (1)
Circuits\RemoteRenderer.cs (1)
29internal readonly ConcurrentQueue<UnacknowledgedRenderBatch> _unacknowledgedRenderBatches = new ConcurrentQueue<UnacknowledgedRenderBatch>();
Microsoft.AspNetCore.Components.Tests (4)
RendererTest.cs (4)
237var log = new ConcurrentQueue<(int id, NestedAsyncComponent.EventType @event)>(); 396var log = new ConcurrentQueue<(int id, NestedAsyncComponent.EventType @event)>(); 440var log = new ConcurrentQueue<(int id, NestedAsyncComponent.EventType @event)>(); 484var log = new ConcurrentQueue<(int id, NestedAsyncComponent.EventType @event)>();
Microsoft.AspNetCore.ConcurrencyLimiter (1)
QueuePolicies\BasePolicy.cs (1)
15private readonly ConcurrentQueue<RateLimitLease> _leases = new ConcurrentQueue<RateLimitLease>();
Microsoft.AspNetCore.Diagnostics.Middleware (2)
Buffering\IncomingRequestLogBuffer.cs (2)
32private ConcurrentQueue<SerializedLogRecord> _activeBuffer = new(); 33private ConcurrentQueue<SerializedLogRecord> _standbyBuffer = new();
Microsoft.AspNetCore.Http (1)
src\Shared\CancellationTokenSourcePool.cs (1)
12private readonly ConcurrentQueue<PooledCancellationTokenSource> _queue = new();
Microsoft.AspNetCore.Http.Extensions (1)
src\Components\Endpoints\src\FormMapping\Converters\CollectionAdapters\ConcurrentQueueBufferAdapter.cs (1)
10public static ConcurrentQueue<TElement> CreateBuffer() => new();
Microsoft.AspNetCore.InternalTesting (5)
Logging\TestSink.cs (4)
21_scopes = new ConcurrentQueue<BeginScopeContext>(); 22_writes = new ConcurrentQueue<WriteContext>(); 29public IProducerConsumerCollection<BeginScopeContext> Scopes { get => _scopes; set => _scopes = new ConcurrentQueue<BeginScopeContext>(value); } 31public IProducerConsumerCollection<WriteContext> Writes { get => _writes; set => _writes = new ConcurrentQueue<WriteContext>(value); }
Tracing\CollectingEventListener.cs (1)
13private readonly ConcurrentQueue<EventWrittenEventArgs> _events = new ConcurrentQueue<EventWrittenEventArgs>();
Microsoft.AspNetCore.OutputCaching (1)
RecyclableReadOnlySequenceSegment.cs (1)
40static readonly ConcurrentQueue<RecyclableReadOnlySequenceSegment> s_Spares = new();
Microsoft.AspNetCore.Server.HttpSys (1)
src\Shared\Buffers.MemoryPool\PinnedBlockMemoryPool.cs (1)
44private readonly ConcurrentQueue<MemoryPoolBlock> _blocks = new ConcurrentQueue<MemoryPoolBlock>();
Microsoft.AspNetCore.Server.IIS (1)
src\Shared\Buffers.MemoryPool\PinnedBlockMemoryPool.cs (1)
44private readonly ConcurrentQueue<MemoryPoolBlock> _blocks = new ConcurrentQueue<MemoryPoolBlock>();
Microsoft.AspNetCore.Server.Kestrel.Core (3)
Internal\Http2\Http2Connection.cs (1)
140private readonly ConcurrentQueue<Http2Stream> _completedStreams = new ConcurrentQueue<Http2Stream>();
src\Shared\Buffers.MemoryPool\PinnedBlockMemoryPool.cs (1)
44private readonly ConcurrentQueue<MemoryPoolBlock> _blocks = new ConcurrentQueue<MemoryPoolBlock>();
src\Shared\CancellationTokenSourcePool.cs (1)
12private readonly ConcurrentQueue<PooledCancellationTokenSource> _queue = new();
Microsoft.AspNetCore.Server.Kestrel.Core.Tests (2)
src\Servers\Kestrel\shared\test\TestApplicationErrorLogger.cs (2)
29public ConcurrentQueue<LogMessage> Messages { get; } = new ConcurrentQueue<LogMessage>(); 31public ConcurrentQueue<object> Scopes { get; } = new ConcurrentQueue<object>();
Microsoft.AspNetCore.Server.Kestrel.Microbenchmarks (4)
src\Servers\Kestrel\shared\test\Http3\Http3InMemory.cs (1)
77internal readonly ConcurrentQueue<TestStreamContext> _streamContextPool = new ConcurrentQueue<TestStreamContext>();
src\Servers\Kestrel\shared\test\TestApplicationErrorLogger.cs (2)
29public ConcurrentQueue<LogMessage> Messages { get; } = new ConcurrentQueue<LogMessage>(); 31public ConcurrentQueue<object> Scopes { get; } = new ConcurrentQueue<object>();
src\Servers\Kestrel\Transport.Sockets\src\Internal\IOQueue.cs (1)
15private readonly ConcurrentQueue<Work> _workItems = new ConcurrentQueue<Work>();
Microsoft.AspNetCore.Server.Kestrel.Transport.NamedPipes (1)
src\Shared\Buffers.MemoryPool\PinnedBlockMemoryPool.cs (1)
44private readonly ConcurrentQueue<MemoryPoolBlock> _blocks = new ConcurrentQueue<MemoryPoolBlock>();
Microsoft.AspNetCore.Server.Kestrel.Transport.Quic (1)
src\Shared\Buffers.MemoryPool\PinnedBlockMemoryPool.cs (1)
44private readonly ConcurrentQueue<MemoryPoolBlock> _blocks = new ConcurrentQueue<MemoryPoolBlock>();
Microsoft.AspNetCore.Server.Kestrel.Transport.Quic.Tests (2)
src\Servers\Kestrel\shared\test\TestApplicationErrorLogger.cs (2)
29public ConcurrentQueue<LogMessage> Messages { get; } = new ConcurrentQueue<LogMessage>(); 31public ConcurrentQueue<object> Scopes { get; } = new ConcurrentQueue<object>();
Microsoft.AspNetCore.Server.Kestrel.Transport.Sockets (2)
Internal\IOQueue.cs (1)
15private readonly ConcurrentQueue<Work> _workItems = new ConcurrentQueue<Work>();
Internal\SocketSenderPool.cs (1)
13private readonly ConcurrentQueue<SocketSender> _queue = new();
Microsoft.AspNetCore.SignalR.StackExchangeRedis.Tests (1)
Docker.cs (1)
211var lines = new ConcurrentQueue<string>();
Microsoft.AspNetCore.SignalR.Tests.Utils (1)
src\Shared\SignalR\LogSinkProvider.cs (1)
17private readonly ConcurrentQueue<LogRecord> _logs = new ConcurrentQueue<LogRecord>();
Microsoft.AspNetCore.Tests (2)
WebApplicationTests.cs (1)
3045private ConcurrentQueue<EventWrittenEventArgs> _events = new ConcurrentQueue<EventWrittenEventArgs>();
WebHostTests.cs (1)
131private ConcurrentQueue<EventWrittenEventArgs> _events = new ConcurrentQueue<EventWrittenEventArgs>();
Microsoft.AspNetCore.WebSockets.Tests (1)
BufferStream.cs (1)
28_bufferedData = new ConcurrentQueue<byte[]>();
Microsoft.Build (16)
AwaitExtensions.cs (1)
158private readonly ConcurrentQueue<Task> _queuedTasks = new ConcurrentQueue<Task>();
BackEnd\Client\MSBuildClientPacketPump.cs (1)
86ReceivedPacketsQueue = new ConcurrentQueue<INodePacket>();
BackEnd\Components\Communications\NodeEndpointInProc.cs (1)
371_packetQueue = new ConcurrentQueue<INodePacket>();
BackEnd\Components\Communications\NodeProviderOutOfProcBase.cs (4)
231possibleRunningNodes = new ConcurrentQueue<Process>(possibleRunningNodesList); 239ConcurrentQueue<NodeContext> nodeContexts = new(); 240ConcurrentQueue<Exception> exceptions = new(); 650_packetWriteQueue = new ConcurrentQueue<INodePacket>();
BackEnd\Components\Logging\LoggingService.cs (1)
1352_eventQueue = new ConcurrentQueue<object>();
BackEnd\Components\RequestBuilder\RequestBuilder.cs (1)
119_pendingResourceRequests = new ConcurrentQueue<Action<ResourceResponse>>();
BackEnd\Node\InProcNode.cs (1)
113_receivedPackets = new ConcurrentQueue<INodePacket>();
BackEnd\Node\OutOfProcNode.cs (1)
143_receivedPackets = new ConcurrentQueue<INodePacket>();
BackEnd\Node\OutOfProcServerNode.cs (1)
82_receivedPackets = new ConcurrentQueue<INodePacket>();
Graph\ParallelWorkSet.cs (1)
34new ConcurrentQueue<Lazy<TResult>>();
Instance\TaskFactories\TaskHostTask.cs (1)
162_receivedPackets = new ConcurrentQueue<INodePacket>();
Logging\ProfilerLogger.cs (1)
29private readonly ConcurrentQueue<ProfilerResult> _profiledResults = new ConcurrentQueue<ProfilerResult>();
NodeEndpointOutOfProcBase.cs (1)
353_packetQueue = new ConcurrentQueue<INodePacket>();
Microsoft.Build.Engine.UnitTests (2)
ProjectCache\ProjectCacheTests.cs (2)
266public ConcurrentQueue<BuildRequestData> Requests { get; } = new(); 272public ConcurrentQueue<int> QueryStartStops = new();
Microsoft.Build.Tasks.Core (3)
Copy.cs (2)
50private static ConcurrentQueue<Action> _copyActionQueue = new ConcurrentQueue<Action>(); 606ConcurrentQueue<List<int>> partitionQueue = new ConcurrentQueue<List<int>>(partitionsByDestination.Values);
GetSDKReferenceFiles.cs (1)
59private readonly ConcurrentQueue<string> _exceptions = new ConcurrentQueue<string>();
Microsoft.Build.UnitTests.Shared (2)
MockEngine.cs (2)
43private readonly ConcurrentQueue<BuildErrorEventArgs> _errorEvents = new ConcurrentQueue<BuildErrorEventArgs>(); 44private readonly ConcurrentQueue<BuildWarningEventArgs> _warningEvents = new ConcurrentQueue<BuildWarningEventArgs>();
Microsoft.CodeAnalysis (6)
Diagnostic\DiagnosticBag.cs (1)
305ConcurrentQueue<Diagnostic> newBag = new ConcurrentQueue<Diagnostic>();
Emit\CommonPEModuleBuilder.cs (5)
886Interlocked.CompareExchange(ref NestedTypes, new ConcurrentQueue<Cci.INestedTypeDefinition>(), null); 978Interlocked.CompareExchange(ref defs.Methods, new ConcurrentQueue<Cci.IMethodDefinition>(), null); 991Interlocked.CompareExchange(ref defs.Properties, new ConcurrentQueue<Cci.IPropertyDefinition>(), null); 1004Interlocked.CompareExchange(ref defs.Fields, new ConcurrentQueue<Cci.IFieldDefinition>(), null); 1026_lazySynthesizedNamespaceMembers.GetOrAdd(container, _ => new ConcurrentQueue<INamespaceOrTypeSymbolInternal>()).Enqueue(typeOrNamespace);
Microsoft.CodeAnalysis.CSharp.Emit3.UnitTests (4)
Semantics\ExtensionTests.cs (4)
43917public ConcurrentQueue<string> _results = new ConcurrentQueue<string>(); 43988public ConcurrentQueue<string> _results = new ConcurrentQueue<string>(); 44036public ConcurrentQueue<string> _results = new ConcurrentQueue<string>(); 44088public ConcurrentQueue<string> _results = new ConcurrentQueue<string>();
Microsoft.CodeAnalysis.CSharp.Scripting.UnitTests (1)
ObjectFormatterTests.cs (1)
699var obj = new ConcurrentQueue<object>();
Microsoft.CodeAnalysis.CSharp.Symbol.UnitTests (2)
Compilation\CompilationAPITests.cs (2)
544var queue = new ConcurrentQueue<MetadataReference> { }; 871var queue = new ConcurrentQueue<SyntaxTree> { };
Microsoft.CodeAnalysis.Features (1)
AddImport\AbstractAddImportFeatureService.cs (1)
178var allReferences = new ConcurrentQueue<Reference>();
Microsoft.CodeAnalysis.Test.Utilities (1)
Diagnostics\TrackingDiagnosticAnalyzer.cs (1)
50private readonly ConcurrentQueue<Entry> _callLog = new ConcurrentQueue<Entry>();
Microsoft.DotNet.Arcade.Sdk.Tests (1)
Utilities\TestProjectFixture.cs (1)
21private readonly ConcurrentQueue<IDisposable> _disposables = new ConcurrentQueue<IDisposable>();
Microsoft.Extensions.Http (1)
DefaultHttpClientFactory.cs (1)
88_expiredHandlers = new ConcurrentQueue<ExpiredHandlerTrackingEntry>();
Microsoft.Extensions.Logging.AzureAppServices (2)
BatchingLoggerProvider.cs (2)
158new BlockingCollection<LogMessage>(new ConcurrentQueue<LogMessage>()) : 159new BlockingCollection<LogMessage>(new ConcurrentQueue<LogMessage>(), _queueSize.Value);
Microsoft.Extensions.ObjectPool (1)
DefaultObjectPool.cs (1)
22private protected readonly ConcurrentQueue<T> _items = new();
Microsoft.Extensions.ServiceDiscovery.Dns.Tests (4)
tests\Shared\Logging\TestSink.cs (4)
20_scopes = new ConcurrentQueue<BeginScopeContext>(); 21_writes = new ConcurrentQueue<WriteContext>(); 28public IProducerConsumerCollection<BeginScopeContext> Scopes { get => _scopes; set => _scopes = new ConcurrentQueue<BeginScopeContext>(value); } 30public IProducerConsumerCollection<WriteContext> Writes { get => _writes; set => _writes = new ConcurrentQueue<WriteContext>(value); }
Microsoft.ML.Core (2)
Data\ProgressReporter.cs (2)
358PendingCheckpoints = new ConcurrentQueue<KeyValuePair<DateTime, ProgressEntry>>(); 369_pendingEvents = new ConcurrentQueue<ProgressEvent>();
Microsoft.ML.Data (1)
DataLoadSave\Text\BlockingQueue.cs (1)
47_queue = new ConcurrentQueue<T>();
Microsoft.ML.FastTree (2)
Training\Applications\ObjectiveFunction.cs (1)
65var queue = new ConcurrentQueue<int>(Enumerable.Range(0, BlockingThreadPool.NumThreads));
Training\WinLossCalculator.cs (1)
55var queue = new ConcurrentQueue<int>(Enumerable.Range(0, BlockingThreadPool.NumThreads));
MSBuild (1)
NodeEndpointOutOfProcBase.cs (1)
353_packetQueue = new ConcurrentQueue<INodePacket>();
Sockets.BindTests (2)
src\Servers\Kestrel\shared\test\TestApplicationErrorLogger.cs (2)
29public ConcurrentQueue<LogMessage> Messages { get; } = new ConcurrentQueue<LogMessage>(); 31public ConcurrentQueue<object> Scopes { get; } = new ConcurrentQueue<object>();
Sockets.FunctionalTests (2)
src\Servers\Kestrel\shared\test\TestApplicationErrorLogger.cs (2)
29public ConcurrentQueue<LogMessage> Messages { get; } = new ConcurrentQueue<LogMessage>(); 31public ConcurrentQueue<object> Scopes { get; } = new ConcurrentQueue<object>();
System.Collections.Concurrent (2)
System\Collections\Concurrent\BlockingCollection.cs (2)
147: this(new ConcurrentQueue<T>()) 162: this(new ConcurrentQueue<T>(), boundedCapacity)
System.Data.Odbc (1)
Common\System\Data\ProviderBase\DbConnectionPool.cs (1)
111private readonly ConcurrentQueue<PendingGetConnection> _pendingOpens = new ConcurrentQueue<PendingGetConnection>();
System.Net.Sockets (1)
System\Net\Sockets\SocketAsyncEngine.Unix.cs (1)
92private readonly ConcurrentQueue<SocketIOEvent> _eventQueue = new ConcurrentQueue<SocketIOEvent>();
System.Private.CoreLib (4)
src\libraries\System.Private.CoreLib\src\System\Threading\ThreadPoolWorkQueue.cs (4)
416internal readonly WorkQueue workItems = new WorkQueue(); 417internal readonly WorkQueue highPriorityWorkItems = new WorkQueue(); 421s_prioritizationExperiment ? new WorkQueue() : null!; 468_assignableWorkItemQueues[i] = new WorkQueue();
System.Threading.Channels (1)
System\Threading\Channels\UnboundedChannel.cs (1)
21private readonly ConcurrentQueue<T> _items = new ConcurrentQueue<T>();
System.Threading.Tasks.Parallel (3)
System\Threading\Tasks\Parallel.cs (2)
282LazyInitializer.EnsureInitialized<ConcurrentQueue<Exception>>(ref exceptionQ, () => { return new ConcurrentQueue<Exception>(); }); 298LazyInitializer.EnsureInitialized<ConcurrentQueue<Exception>>(ref exceptionQ, () => { return new ConcurrentQueue<Exception>(); });
System\Threading\Tasks\TaskReplicator.cs (1)
21private readonly ConcurrentQueue<Replica> _pendingReplicas = new ConcurrentQueue<Replica>();
243 references to ConcurrentQueue
Aspire.Confluent.Kafka (3)
ConfluentKafkaMetrics.cs (3)
22public ConcurrentQueue<Measurement<long>> ReplyQueueMeasurements { get; } = new ConcurrentQueue<Measurement<long>>(); 23public ConcurrentQueue<Measurement<long>> MessageCountMeasurements { get; } = new ConcurrentQueue<Measurement<long>>(); 24public ConcurrentQueue<Measurement<long>> MessageSizeMeasurements { get; } = new ConcurrentQueue<Measurement<long>>();
Aspire.Dashboard.Components.Tests (2)
tests\Shared\Logging\TestSink.cs (2)
10private ConcurrentQueue<BeginScopeContext> _scopes; 11private ConcurrentQueue<WriteContext> _writes;
Aspire.Dashboard.Tests (2)
tests\Shared\Logging\TestSink.cs (2)
10private ConcurrentQueue<BeginScopeContext> _scopes; 11private ConcurrentQueue<WriteContext> _writes;
Aspire.Hosting.Analyzers (1)
AppHostAnalyzer.cs (1)
34var concurrentQueue = new ConcurrentQueue<ConcurrentDictionary<ModelNameOperation, byte>>();
Aspire.Hosting.Testing.Tests (2)
tests\Shared\Logging\TestSink.cs (2)
10private ConcurrentQueue<BeginScopeContext> _scopes; 11private ConcurrentQueue<WriteContext> _writes;
Aspire.Hosting.Tests (4)
Dcp\TestKubernetesService.cs (2)
24public ConcurrentQueue<CustomResource> CreatedResources { get; } = []; 25public ConcurrentQueue<string> DeletedResources { get; } = [];
tests\Shared\Logging\TestSink.cs (2)
10private ConcurrentQueue<BeginScopeContext> _scopes; 11private ConcurrentQueue<WriteContext> _writes;
Aspire.Playground.Tests (2)
tests\Shared\Logging\TestSink.cs (2)
10private ConcurrentQueue<BeginScopeContext> _scopes; 11private ConcurrentQueue<WriteContext> _writes;
dotnet-svcutil-lib (1)
FrameworkFork\System.ServiceModel\Internals\System\Runtime\Diagnostics\EtwDiagnosticTrace.cs (1)
453private static readonly ConcurrentQueue<StringBuilder> s_freeStringBuilders = new ConcurrentQueue<StringBuilder>();
Infrastructure.Common (1)
xunit\WcfTestCase.cs (1)
51ConcurrentQueue<EventWrittenEventArgs> events = new ConcurrentQueue<EventWrittenEventArgs>();
InMemory.FunctionalTests (5)
EventSourceTests.cs (1)
423private readonly ConcurrentQueue<EventSnapshot> _events = new ConcurrentQueue<EventSnapshot>();
src\Servers\Kestrel\shared\test\Http3\Http3InMemory.cs (1)
77internal readonly ConcurrentQueue<TestStreamContext> _streamContextPool = new ConcurrentQueue<TestStreamContext>();
src\Servers\Kestrel\shared\test\TestApplicationErrorLogger.cs (2)
29public ConcurrentQueue<LogMessage> Messages { get; } = new ConcurrentQueue<LogMessage>(); 31public ConcurrentQueue<object> Scopes { get; } = new ConcurrentQueue<object>();
src\Servers\Kestrel\shared\test\TestApplicationErrorLoggerLoggedTest.cs (1)
18public ConcurrentQueue<LogMessage> LogMessages => TestApplicationErrorLogger.Messages;
Interop.FunctionalTests (1)
src\Shared\Buffers.MemoryPool\PinnedBlockMemoryPool.cs (1)
44private readonly ConcurrentQueue<MemoryPoolBlock> _blocks = new ConcurrentQueue<MemoryPoolBlock>();
Microsoft.AspNetCore.App.Analyzers (2)
Mvc\MvcAnalyzer.cs (1)
40var concurrentQueue = new ConcurrentQueue<(List<ActionRoute> ActionRoutes, List<AttributeInfo> AuthorizeAttributes)>();
RouteHandlers\RouteHandlerAnalyzer.cs (1)
47var concurrentQueue = new ConcurrentQueue<ConcurrentDictionary<MapOperation, byte>>();
Microsoft.AspNetCore.Components.Endpoints (11)
FormMapping\Converters\CollectionAdapters\ConcurrentQueueBufferAdapter.cs (7)
8internal sealed class ConcurrentQueueBufferAdapter<TElement> : ICollectionBufferAdapter<ConcurrentQueue<TElement>, ConcurrentQueue<TElement>, TElement> 10public static ConcurrentQueue<TElement> CreateBuffer() => new(); 12public static ConcurrentQueue<TElement> Add(ref ConcurrentQueue<TElement> buffer, TElement element) 18public static ConcurrentQueue<TElement> ToResult(ConcurrentQueue<TElement> buffer) => buffer;
FormMapping\Factories\Collections\TypedCollectionConverterFactory.cs (4)
53var _ when type == (typeof(ConcurrentQueue<TElement>)) => true, 145var _ when type.IsAssignableTo(typeof(ConcurrentQueue<TElement>)) => 146new CollectionConverter<ConcurrentQueue<TElement>, ConcurrentQueueBufferAdapter<TElement>, ConcurrentQueue<TElement>, TElement>(elementTypeConverter),
Microsoft.AspNetCore.Components.Endpoints.Tests (3)
Binding\FormDataMapperTests.cs (3)
793var expected = new ConcurrentQueue<int>(new[] { 10, 11, 12, 13, 14, 15, 16, 17, 18, 19 }); 794CanDeserialize_Collection<ConcurrentQueue<int>, ConcurrentQueue<int>, int>(expected);
Microsoft.AspNetCore.Components.Server (1)
Circuits\RemoteRenderer.cs (1)
29internal readonly ConcurrentQueue<UnacknowledgedRenderBatch> _unacknowledgedRenderBatches = new ConcurrentQueue<UnacknowledgedRenderBatch>();
Microsoft.AspNetCore.Components.Tests (5)
RendererTest.cs (5)
237var log = new ConcurrentQueue<(int id, NestedAsyncComponent.EventType @event)>(); 396var log = new ConcurrentQueue<(int id, NestedAsyncComponent.EventType @event)>(); 440var log = new ConcurrentQueue<(int id, NestedAsyncComponent.EventType @event)>(); 484var log = new ConcurrentQueue<(int id, NestedAsyncComponent.EventType @event)>(); 5707[Parameter] public ConcurrentQueue<(int testId, EventType @event)> Log { get; set; }
Microsoft.AspNetCore.ConcurrencyLimiter (1)
QueuePolicies\BasePolicy.cs (1)
15private readonly ConcurrentQueue<RateLimitLease> _leases = new ConcurrentQueue<RateLimitLease>();
Microsoft.AspNetCore.Diagnostics.Middleware (3)
Buffering\IncomingRequestLogBuffer.cs (3)
32private ConcurrentQueue<SerializedLogRecord> _activeBuffer = new(); 33private ConcurrentQueue<SerializedLogRecord> _standbyBuffer = new(); 103ConcurrentQueue<SerializedLogRecord> tempBuffer;
Microsoft.AspNetCore.Http (1)
src\Shared\CancellationTokenSourcePool.cs (1)
12private readonly ConcurrentQueue<PooledCancellationTokenSource> _queue = new();
Microsoft.AspNetCore.Http.Extensions (11)
src\Components\Endpoints\src\FormMapping\Converters\CollectionAdapters\ConcurrentQueueBufferAdapter.cs (7)
8internal sealed class ConcurrentQueueBufferAdapter<TElement> : ICollectionBufferAdapter<ConcurrentQueue<TElement>, ConcurrentQueue<TElement>, TElement> 10public static ConcurrentQueue<TElement> CreateBuffer() => new(); 12public static ConcurrentQueue<TElement> Add(ref ConcurrentQueue<TElement> buffer, TElement element) 18public static ConcurrentQueue<TElement> ToResult(ConcurrentQueue<TElement> buffer) => buffer;
src\Components\Endpoints\src\FormMapping\Factories\Collections\TypedCollectionConverterFactory.cs (4)
53var _ when type == (typeof(ConcurrentQueue<TElement>)) => true, 145var _ when type.IsAssignableTo(typeof(ConcurrentQueue<TElement>)) => 146new CollectionConverter<ConcurrentQueue<TElement>, ConcurrentQueueBufferAdapter<TElement>, ConcurrentQueue<TElement>, TElement>(elementTypeConverter),
Microsoft.AspNetCore.InternalTesting (3)
Logging\TestSink.cs (2)
11private ConcurrentQueue<BeginScopeContext> _scopes; 12private ConcurrentQueue<WriteContext> _writes;
Tracing\CollectingEventListener.cs (1)
13private readonly ConcurrentQueue<EventWrittenEventArgs> _events = new ConcurrentQueue<EventWrittenEventArgs>();
Microsoft.AspNetCore.OutputCaching (1)
RecyclableReadOnlySequenceSegment.cs (1)
40static readonly ConcurrentQueue<RecyclableReadOnlySequenceSegment> s_Spares = new();
Microsoft.AspNetCore.Server.HttpSys (1)
src\Shared\Buffers.MemoryPool\PinnedBlockMemoryPool.cs (1)
44private readonly ConcurrentQueue<MemoryPoolBlock> _blocks = new ConcurrentQueue<MemoryPoolBlock>();
Microsoft.AspNetCore.Server.IIS (1)
src\Shared\Buffers.MemoryPool\PinnedBlockMemoryPool.cs (1)
44private readonly ConcurrentQueue<MemoryPoolBlock> _blocks = new ConcurrentQueue<MemoryPoolBlock>();
Microsoft.AspNetCore.Server.Kestrel.Core (3)
Internal\Http2\Http2Connection.cs (1)
140private readonly ConcurrentQueue<Http2Stream> _completedStreams = new ConcurrentQueue<Http2Stream>();
src\Shared\Buffers.MemoryPool\PinnedBlockMemoryPool.cs (1)
44private readonly ConcurrentQueue<MemoryPoolBlock> _blocks = new ConcurrentQueue<MemoryPoolBlock>();
src\Shared\CancellationTokenSourcePool.cs (1)
12private readonly ConcurrentQueue<PooledCancellationTokenSource> _queue = new();
Microsoft.AspNetCore.Server.Kestrel.Core.Tests (3)
src\Servers\Kestrel\shared\test\TestApplicationErrorLogger.cs (2)
29public ConcurrentQueue<LogMessage> Messages { get; } = new ConcurrentQueue<LogMessage>(); 31public ConcurrentQueue<object> Scopes { get; } = new ConcurrentQueue<object>();
src\Servers\Kestrel\shared\test\TestApplicationErrorLoggerLoggedTest.cs (1)
18public ConcurrentQueue<LogMessage> LogMessages => TestApplicationErrorLogger.Messages;
Microsoft.AspNetCore.Server.Kestrel.Microbenchmarks (4)
src\Servers\Kestrel\shared\test\Http3\Http3InMemory.cs (1)
77internal readonly ConcurrentQueue<TestStreamContext> _streamContextPool = new ConcurrentQueue<TestStreamContext>();
src\Servers\Kestrel\shared\test\TestApplicationErrorLogger.cs (2)
29public ConcurrentQueue<LogMessage> Messages { get; } = new ConcurrentQueue<LogMessage>(); 31public ConcurrentQueue<object> Scopes { get; } = new ConcurrentQueue<object>();
src\Servers\Kestrel\Transport.Sockets\src\Internal\IOQueue.cs (1)
15private readonly ConcurrentQueue<Work> _workItems = new ConcurrentQueue<Work>();
Microsoft.AspNetCore.Server.Kestrel.Transport.NamedPipes (1)
src\Shared\Buffers.MemoryPool\PinnedBlockMemoryPool.cs (1)
44private readonly ConcurrentQueue<MemoryPoolBlock> _blocks = new ConcurrentQueue<MemoryPoolBlock>();
Microsoft.AspNetCore.Server.Kestrel.Transport.Quic (1)
src\Shared\Buffers.MemoryPool\PinnedBlockMemoryPool.cs (1)
44private readonly ConcurrentQueue<MemoryPoolBlock> _blocks = new ConcurrentQueue<MemoryPoolBlock>();
Microsoft.AspNetCore.Server.Kestrel.Transport.Quic.Tests (3)
src\Servers\Kestrel\shared\test\TestApplicationErrorLogger.cs (2)
29public ConcurrentQueue<LogMessage> Messages { get; } = new ConcurrentQueue<LogMessage>(); 31public ConcurrentQueue<object> Scopes { get; } = new ConcurrentQueue<object>();
src\Servers\Kestrel\shared\test\TestApplicationErrorLoggerLoggedTest.cs (1)
18public ConcurrentQueue<LogMessage> LogMessages => TestApplicationErrorLogger.Messages;
Microsoft.AspNetCore.Server.Kestrel.Transport.Sockets (2)
Internal\IOQueue.cs (1)
15private readonly ConcurrentQueue<Work> _workItems = new ConcurrentQueue<Work>();
Internal\SocketSenderPool.cs (1)
13private readonly ConcurrentQueue<SocketSender> _queue = new();
Microsoft.AspNetCore.SignalR.StackExchangeRedis.Tests (2)
Docker.cs (2)
195private static (Process, ConcurrentQueue<string>) RunProcess(string fileName, string arguments, string prefix, ILogger logger) 211var lines = new ConcurrentQueue<string>();
Microsoft.AspNetCore.SignalR.Tests.Utils (1)
src\Shared\SignalR\LogSinkProvider.cs (1)
17private readonly ConcurrentQueue<LogRecord> _logs = new ConcurrentQueue<LogRecord>();
Microsoft.AspNetCore.Tests (2)
WebApplicationTests.cs (1)
3045private ConcurrentQueue<EventWrittenEventArgs> _events = new ConcurrentQueue<EventWrittenEventArgs>();
WebHostTests.cs (1)
131private ConcurrentQueue<EventWrittenEventArgs> _events = new ConcurrentQueue<EventWrittenEventArgs>();
Microsoft.AspNetCore.WebSockets.Tests (1)
BufferStream.cs (1)
18private readonly ConcurrentQueue<byte[]> _bufferedData;
Microsoft.Build (20)
AwaitExtensions.cs (1)
158private readonly ConcurrentQueue<Task> _queuedTasks = new ConcurrentQueue<Task>();
BackEnd\Client\MSBuildClientPacketPump.cs (1)
24public ConcurrentQueue<INodePacket> ReceivedPacketsQueue { get; }
BackEnd\Components\Communications\NodeEndpointInProc.cs (1)
93private ConcurrentQueue<INodePacket> _packetQueue;
BackEnd\Components\Communications\NodeProviderOutOfProcBase.cs (4)
224ConcurrentQueue<Process> possibleRunningNodes = null; 239ConcurrentQueue<NodeContext> nodeContexts = new(); 240ConcurrentQueue<Exception> exceptions = new(); 595private readonly ConcurrentQueue<INodePacket> _packetWriteQueue;
BackEnd\Components\Logging\LoggingService.cs (2)
250private ConcurrentQueue<object> _eventQueue; 1371var eventQueue = _eventQueue;
BackEnd\Components\RequestBuilder\RequestBuilder.cs (1)
60private ConcurrentQueue<Action<ResourceResponse>> _pendingResourceRequests;
BackEnd\Node\InProcNode.cs (1)
54private readonly ConcurrentQueue<INodePacket> _receivedPackets;
BackEnd\Node\OutOfProcNode.cs (1)
104private readonly ConcurrentQueue<INodePacket> _receivedPackets;
BackEnd\Node\OutOfProcServerNode.cs (1)
50private readonly ConcurrentQueue<INodePacket> _receivedPackets;
Collections\ConcurrentQueueExtensions.cs (1)
20public static T Dequeue<T>(this ConcurrentQueue<T> stack) where T : class
Graph\ParallelWorkSet.cs (1)
33private readonly ConcurrentQueue<Lazy<TResult>> _queue =
Instance\TaskFactories\TaskHostTask.cs (1)
70private ConcurrentQueue<INodePacket> _receivedPackets;
Logging\ProfilerLogger.cs (1)
29private readonly ConcurrentQueue<ProfilerResult> _profiledResults = new ConcurrentQueue<ProfilerResult>();
NodeEndpointOutOfProcBase.cs (3)
107private ConcurrentQueue<INodePacket> _packetQueue; 369ConcurrentQueue<INodePacket> localPacketQueue = _packetQueue; 601ConcurrentQueue<INodePacket> localPacketQueue,
Microsoft.Build.Engine.UnitTests (2)
ProjectCache\ProjectCacheTests.cs (2)
266public ConcurrentQueue<BuildRequestData> Requests { get; } = new(); 272public ConcurrentQueue<int> QueryStartStops = new();
Microsoft.Build.Tasks.Core (5)
Copy.cs (2)
50private static ConcurrentQueue<Action> _copyActionQueue = new ConcurrentQueue<Action>(); 606ConcurrentQueue<List<int>> partitionQueue = new ConcurrentQueue<List<int>>(partitionsByDestination.Values);
GetSDKReferenceFiles.cs (3)
59private readonly ConcurrentQueue<string> _exceptions = new ConcurrentQueue<string>(); 888private readonly ConcurrentQueue<string> _exceptionMessages; 913internal SDKFilesCache(ConcurrentQueue<string> exceptionQueue, string cacheFileDirectory, GetAssemblyName getAssemblyName, GetAssemblyRuntimeVersion getRuntimeVersion, FileExists fileExists)
Microsoft.Build.UnitTests.Shared (2)
MockEngine.cs (2)
43private readonly ConcurrentQueue<BuildErrorEventArgs> _errorEvents = new ConcurrentQueue<BuildErrorEventArgs>(); 44private readonly ConcurrentQueue<BuildWarningEventArgs> _warningEvents = new ConcurrentQueue<BuildWarningEventArgs>();
Microsoft.CodeAnalysis (19)
Diagnostic\DiagnosticBag.cs (13)
34private ConcurrentQueue<Diagnostic>? _lazyBag; 51ConcurrentQueue<Diagnostic>? bag = _lazyBag; 117ConcurrentQueue<Diagnostic> bag = this.Bag; 128ConcurrentQueue<Diagnostic> bag = this.Bag; 173ConcurrentQueue<Diagnostic>? oldBag = _lazyBag; 186ConcurrentQueue<Diagnostic>? oldBag = _lazyBag; 195private static ImmutableArray<TDiagnostic> ToReadOnlyCore<TDiagnostic>(ConcurrentQueue<Diagnostic>? oldBag, bool forceResolution) where TDiagnostic : Diagnostic 229ConcurrentQueue<Diagnostic> bag = this.Bag; 295private ConcurrentQueue<Diagnostic> Bag 299ConcurrentQueue<Diagnostic>? bag = _lazyBag; 305ConcurrentQueue<Diagnostic> newBag = new ConcurrentQueue<Diagnostic>(); 316ConcurrentQueue<Diagnostic>? bag = _lazyBag; 361ConcurrentQueue<Diagnostic>? lazyBag = _bag._lazyBag;
Emit\CommonPEModuleBuilder.cs (6)
863private ConcurrentQueue<Cci.INestedTypeDefinition> NestedTypes; 864public ConcurrentQueue<Cci.IMethodDefinition> Methods; 865public ConcurrentQueue<Cci.IPropertyDefinition> Properties; 866public ConcurrentQueue<Cci.IFieldDefinition> Fields; 935private ConcurrentDictionary<INamespaceSymbolInternal, ConcurrentQueue<INamespaceOrTypeSymbolInternal>> _lazySynthesizedNamespaceMembers; 1023Interlocked.CompareExchange(ref _lazySynthesizedNamespaceMembers, new ConcurrentDictionary<INamespaceSymbolInternal, ConcurrentQueue<INamespaceOrTypeSymbolInternal>>(), null);
Microsoft.CodeAnalysis.CSharp.Emit3.UnitTests (4)
Semantics\ExtensionTests.cs (4)
43917public ConcurrentQueue<string> _results = new ConcurrentQueue<string>(); 43988public ConcurrentQueue<string> _results = new ConcurrentQueue<string>(); 44036public ConcurrentQueue<string> _results = new ConcurrentQueue<string>(); 44088public ConcurrentQueue<string> _results = new ConcurrentQueue<string>();
Microsoft.CodeAnalysis.CSharp.Scripting.UnitTests (1)
ObjectFormatterTests.cs (1)
699var obj = new ConcurrentQueue<object>();
Microsoft.CodeAnalysis.CSharp.Symbol.UnitTests (2)
Compilation\CompilationAPITests.cs (2)
544var queue = new ConcurrentQueue<MetadataReference> { }; 871var queue = new ConcurrentQueue<SyntaxTree> { };
Microsoft.CodeAnalysis.Features (10)
AddImport\AbstractAddImportFeatureService.cs (6)
178var allReferences = new ConcurrentQueue<Reference>(); 207ConcurrentQueue<Reference> allSymbolReferences, SymbolReferenceFinder finder, bool exact, CancellationToken cancellationToken) 216Project project, ConcurrentQueue<Reference> allSymbolReferences, int maxResults, 261Project project, ConcurrentQueue<Reference> allSymbolReferences, int maxResults, SymbolReferenceFinder finder, 349ConcurrentQueue<Reference> allSymbolReferences, 474private static void AddRange(ConcurrentQueue<Reference> allSymbolReferences, ImmutableArray<SymbolReference> proposedReferences)
AddImport\SymbolReferenceFinder_PackageAssemblySearch.cs (4)
22ConcurrentQueue<Reference> allReferences, bool exact, CancellationToken cancellationToken) 125ConcurrentQueue<Reference> allReferences, 154ConcurrentQueue<Reference> allReferences, 182ConcurrentQueue<Reference> allReferences,
Microsoft.CodeAnalysis.Test.Utilities (1)
Diagnostics\TrackingDiagnosticAnalyzer.cs (1)
50private readonly ConcurrentQueue<Entry> _callLog = new ConcurrentQueue<Entry>();
Microsoft.CodeAnalysis.VisualBasic (1)
Compilation\VisualBasicCompilation.vb (1)
112Private _lazyImportInfos As ConcurrentQueue(Of ImportInfo)
Microsoft.DotNet.Arcade.Sdk.Tests (1)
Utilities\TestProjectFixture.cs (1)
21private readonly ConcurrentQueue<IDisposable> _disposables = new ConcurrentQueue<IDisposable>();
Microsoft.Extensions.Http (1)
DefaultHttpClientFactory.cs (1)
59internal readonly ConcurrentQueue<ExpiredHandlerTrackingEntry> _expiredHandlers;
Microsoft.Extensions.ObjectPool (1)
DefaultObjectPool.cs (1)
22private protected readonly ConcurrentQueue<T> _items = new();
Microsoft.Extensions.ServiceDiscovery.Dns.Tests (2)
tests\Shared\Logging\TestSink.cs (2)
10private ConcurrentQueue<BeginScopeContext> _scopes; 11private ConcurrentQueue<WriteContext> _writes;
Microsoft.ML.Core (2)
Data\ProgressReporter.cs (2)
298private readonly ConcurrentQueue<ProgressEvent> _pendingEvents; 343public readonly ConcurrentQueue<KeyValuePair<DateTime, ProgressEntry>> PendingCheckpoints;
Microsoft.ML.Data (1)
DataLoadSave\Text\BlockingQueue.cs (1)
35private readonly ConcurrentQueue<T> _queue;
Microsoft.ML.FastTree (2)
Training\Applications\ObjectiveFunction.cs (1)
65var queue = new ConcurrentQueue<int>(Enumerable.Range(0, BlockingThreadPool.NumThreads));
Training\WinLossCalculator.cs (1)
55var queue = new ConcurrentQueue<int>(Enumerable.Range(0, BlockingThreadPool.NumThreads));
Microsoft.VisualStudio.LanguageServices (5)
LanguageService\PackageLoadTasks.cs (5)
27private readonly ConcurrentQueue<WorkTask> _backgroundThreadWorkTasks = []; 28private readonly ConcurrentQueue<WorkTask> _mainThreadWorkTasks = []; 33var workTasks = GetWorkTasks(isMainThreadTask); 51private ConcurrentQueue<WorkTask> GetWorkTasks(bool isMainThreadTask) 56var workTasks = GetWorkTasks(isMainThreadTask);
MSBuild (3)
NodeEndpointOutOfProcBase.cs (3)
107private ConcurrentQueue<INodePacket> _packetQueue; 369ConcurrentQueue<INodePacket> localPacketQueue = _packetQueue; 601ConcurrentQueue<INodePacket> localPacketQueue,
mscorlib (1)
src\libraries\shims\mscorlib\ref\mscorlib.cs (1)
78[assembly: System.Runtime.CompilerServices.TypeForwardedTo(typeof(System.Collections.Concurrent.ConcurrentQueue<>))]
netstandard (1)
netstandard.cs (1)
96[assembly: System.Runtime.CompilerServices.TypeForwardedTo(typeof(System.Collections.Concurrent.ConcurrentQueue<>))]
Sockets.BindTests (3)
src\Servers\Kestrel\shared\test\TestApplicationErrorLogger.cs (2)
29public ConcurrentQueue<LogMessage> Messages { get; } = new ConcurrentQueue<LogMessage>(); 31public ConcurrentQueue<object> Scopes { get; } = new ConcurrentQueue<object>();
src\Servers\Kestrel\shared\test\TestApplicationErrorLoggerLoggedTest.cs (1)
18public ConcurrentQueue<LogMessage> LogMessages => TestApplicationErrorLogger.Messages;
Sockets.FunctionalTests (3)
src\Servers\Kestrel\shared\test\TestApplicationErrorLogger.cs (2)
29public ConcurrentQueue<LogMessage> Messages { get; } = new ConcurrentQueue<LogMessage>(); 31public ConcurrentQueue<object> Scopes { get; } = new ConcurrentQueue<object>();
src\Servers\Kestrel\shared\test\TestApplicationErrorLoggerLoggedTest.cs (1)
18public ConcurrentQueue<LogMessage> LogMessages => TestApplicationErrorLogger.Messages;
System.Collections.Concurrent (3)
artifacts\obj\System.Collections.Concurrent\Debug\net10.0\System.Collections.Concurrent.Forwards.cs (1)
3[assembly: System.Runtime.CompilerServices.TypeForwardedTo(typeof(System.Collections.Concurrent.ConcurrentQueue<>))]
System\Collections\Concurrent\BlockingCollection.cs (2)
144/// The default underlying collection is a <see cref="System.Collections.Concurrent.ConcurrentQueue{T}">ConcurrentQueue&lt;T&gt;</see>. 159/// The default underlying collection is a <see cref="System.Collections.Concurrent.ConcurrentQueue{T}">ConcurrentQueue&lt;T&gt;</see>.
System.Data.Odbc (1)
Common\System\Data\ProviderBase\DbConnectionPool.cs (1)
111private readonly ConcurrentQueue<PendingGetConnection> _pendingOpens = new ConcurrentQueue<PendingGetConnection>();
System.Net.Sockets (3)
System\Net\Sockets\SocketAsyncEngine.Unix.cs (3)
92private readonly ConcurrentQueue<SocketIOEvent> _eventQueue = new ConcurrentQueue<SocketIOEvent>(); 280ConcurrentQueue<SocketIOEvent> eventQueue = _eventQueue; 357private readonly ConcurrentQueue<SocketIOEvent> _eventQueue;
System.Private.CoreLib (42)
src\libraries\System.Private.CoreLib\src\System\Collections\Concurrent\ConcurrentQueue.cs (28)
17/// All public and protected members of <see cref="ConcurrentQueue{T}"/> are thread-safe and may be used 62/// Initializes a new instance of the <see cref="ConcurrentQueue{T}"/> class. 71/// Initializes a new instance of the <see cref="ConcurrentQueue{T}"/> class that contains elements copied 75/// The collection whose elements are copied to the new <see cref="ConcurrentQueue{T}"/>. 115/// elements copied from the <see cref="ConcurrentQueue{T}"/>. <paramref name="array"/> must have 158/// with the SyncRoot; otherwise, false. For <see cref="ConcurrentQueue{T}"/>, this property always 181/// <remarks>For <see cref="ConcurrentQueue{T}"/>, this operation will always add the object to the 182/// end of the <see cref="ConcurrentQueue{T}"/> 198/// <remarks>For <see cref="ConcurrentQueue{T}"/>, this operation will attempt to remove the object 199/// from the beginning of the <see cref="ConcurrentQueue{T}"/>. 204/// Gets a value that indicates whether the <see cref="ConcurrentQueue{T}"/> is empty. 206/// <value>true if the <see cref="ConcurrentQueue{T}"/> is empty; otherwise, false.</value> 220/// <summary>Copies the elements stored in the <see cref="ConcurrentQueue{T}"/> to a new array.</summary> 221/// <returns>A new array containing a snapshot of elements copied from the <see cref="ConcurrentQueue{T}"/>.</returns> 248/// Gets the number of elements contained in the <see cref="ConcurrentQueue{T}"/>. 250/// <value>The number of elements contained in the <see cref="ConcurrentQueue{T}"/>.</value> 420/// Copies the <see cref="ConcurrentQueue{T}"/> elements to an existing one-dimensional <see 425/// <see cref="ConcurrentQueue{T}"/>. The <see cref="Array">Array</see> must have zero-based 435/// -or- The number of elements in the source <see cref="ConcurrentQueue{T}"/> is greater than the 472/// <summary>Returns an enumerator that iterates through the <see cref="ConcurrentQueue{T}"/>.</summary> 474/// cref="ConcurrentQueue{T}"/>.</returns> 597/// <summary>Adds an object to the end of the <see cref="ConcurrentQueue{T}"/>.</summary> 599/// The object to add to the end of the <see cref="ConcurrentQueue{T}"/>. 658/// cref="ConcurrentQueue{T}"/>. 666/// <see cref="ConcurrentQueue{T}"/> successfully; otherwise, false. 738/// Attempts to return an object from the beginning of the <see cref="ConcurrentQueue{T}"/> 743/// the beginning of the <see cref="ConcurrentQueue{T}"/> or default(T) 809/// Removes all objects from the <see cref="ConcurrentQueue{T}"/>.
src\libraries\System.Private.CoreLib\src\System\Collections\Concurrent\ConcurrentQueueSegment.cs (1)
16/// These segments are linked together to form the unbounded <see cref="ConcurrentQueue{T}"/>.
src\libraries\System.Private.CoreLib\src\System\Collections\Concurrent\IProducerConsumerCollection.cs (1)
36/// -or- The number of elements in the source <see cref="ConcurrentQueue{T}"/> is greater than the
src\libraries\System.Private.CoreLib\src\System\Threading\ThreadPoolWorkQueue.cs (12)
18using WorkQueue = System.Collections.Concurrent.ConcurrentQueue<object>; 416internal readonly WorkQueue workItems = new WorkQueue(); 417internal readonly WorkQueue highPriorityWorkItems = new WorkQueue(); 420internal readonly WorkQueue lowPriorityWorkItems = 427internal readonly WorkQueue[] _assignableWorkItemQueues = 428new WorkQueue[s_assignableWorkItemQueueCount]; 573WorkQueue queue = tl.assignedGlobalWorkItemQueue; 653WorkQueue queue = 675WorkQueue queue; 931WorkQueue queue = 1275public WorkQueue assignedGlobalWorkItemQueue; 1954foreach (WorkQueue queue in s_workQueue._assignableWorkItemQueues)
System.Text.Json (3)
System\Text\Json\Serialization\Converters\Collection\ConcurrentQueueOfTConverter.cs (1)
11where TCollection : ConcurrentQueue<TElement>
System\Text\Json\Serialization\Converters\Collection\IEnumerableConverterFactory.cs (1)
136else if ((actualTypeToConvert = typeToConvert.GetCompatibleGenericBaseClass(typeof(ConcurrentQueue<>))) != null)
System\Text\Json\Serialization\Metadata\JsonMetadataServices.Collections.cs (1)
298where TCollection : ConcurrentQueue<TElement>
System.Text.Json.SourceGeneration (1)
Helpers\KnownTypeSymbols.cs (1)
64public INamedTypeSymbol? ConcurrentQueueType => GetOrResolveType(typeof(ConcurrentQueue<>), ref _ConcurrentQueueType);
System.Threading.Channels (1)
System\Threading\Channels\UnboundedChannel.cs (1)
21private readonly ConcurrentQueue<T> _items = new ConcurrentQueue<T>();
System.Threading.Tasks.Parallel (5)
System\Threading\Tasks\Parallel.cs (3)
253ConcurrentQueue<Exception>? exceptionQ = null; // will be lazily initialized if necessary 282LazyInitializer.EnsureInitialized<ConcurrentQueue<Exception>>(ref exceptionQ, () => { return new ConcurrentQueue<Exception>(); }); 298LazyInitializer.EnsureInitialized<ConcurrentQueue<Exception>>(ref exceptionQ, () => { return new ConcurrentQueue<Exception>(); });
System\Threading\Tasks\TaskReplicator.cs (2)
21private readonly ConcurrentQueue<Replica> _pendingReplicas = new ConcurrentQueue<Replica>(); 22private ConcurrentQueue<Exception>? _exceptions;