Implemented interface members:
property
Count
System.Collections.Generic.IReadOnlyCollection<T>.Count
property
Count
System.Collections.ICollection.Count
286 references to Count
ConfigurationSchemaGenerator (4)
ConfigSchemaEmitter.cs (1)
103if (pathSegments.Count == 0)
ConfigurationBindingGenerator.ForSchemaGeneration.cs (2)
66Debug.Assert(_typesToParse.Count == 1, "there should only be one type to parse to start."); 69while (_typesToParse.Count > 0)
RuntimeSource\Configuration.Binder\ConfigurationBindingGenerator.Parser.cs (1)
105while (_typesToParse.Count > 0)
dotnet-svcutil-lib (20)
FrameworkFork\Microsoft.Xml\Xml\Serialization\CodeGenerator.cs (1)
245if (freeLocalQueue.Count == 0)
FrameworkFork\System.Runtime.Serialization\System\Runtime\Serialization\ExtensionDataReader.cs (1)
72IDataNode deserializedDataNode = (_deserializedDataNodes == null || _deserializedDataNodes.Count == 0) ? null : _deserializedDataNodes.Dequeue();
FrameworkFork\System.ServiceModel\Internals\System\Runtime\InputQueue.cs (10)
231if (_readerQueue.Count > 0) 236if (_queueState == QueueState.Shutdown && _readerQueue.Count > 0 && _itemQueue.ItemCount == 0) 238outstandingReaders = new IQueueReader[_readerQueue.Count]; 373if (_readerQueue.Count > 0 && _itemQueue.ItemCount == 0) 375outstandingReaders = new IQueueReader[_readerQueue.Count]; 458while (_readerQueue.Count > 0) 594if (_readerQueue.Count == 0) 605if (_readerQueue.Count == 0) 665if (_readerQueue.Count == 0 && _waiterList.Count == 0) 708for (int i = _readerQueue.Count; i > 0; i--)
FrameworkFork\System.ServiceModel\System\ServiceModel\Channels\QueuedObjectPool.cs (3)
61if (_objectQueue.Count < _maxFreeCount && !_isClosed) 77if (_objectQueue.Count == 0) 111Contract.Assert(_objectQueue.Count == 0, "The object queue must be empty for new allocations");
FrameworkFork\System.ServiceModel\System\ServiceModel\Channels\ServiceChannel.cs (1)
2164if (_queue.Count > 0)
FrameworkFork\System.ServiceModel\System\ServiceModel\Dispatcher\ConcurrencyBehavior.cs (4)
235return (((_calloutMessageQueue != null) && (_calloutMessageQueue.Count > 0)) || 236((_newMessageQueue != null) && (_newMessageQueue.Count > 0))); 244if (queue.Count == 0) 255if ((_calloutMessageQueue != null) && (_calloutMessageQueue.Count > 0))
illink (14)
Metrics (2)
src\RoslynAnalyzers\Utilities\Compiler\CodeMetrics\MetricsHelper.cs (1)
323} while (nodesToProcess.Count != 0);
src\RoslynAnalyzers\Utilities\Compiler\Extensions\IOperationExtensions.cs (1)
173while (operationsToProcess.Count > 0)
Metrics.Legacy (2)
src\RoslynAnalyzers\Utilities\Compiler\CodeMetrics\MetricsHelper.cs (1)
323} while (nodesToProcess.Count != 0);
src\RoslynAnalyzers\Utilities\Compiler\Extensions\IOperationExtensions.cs (1)
173while (operationsToProcess.Count > 0)
Microsoft.AspNetCore.Components (5)
RenderTree\Renderer.cs (5)
776if (_batchBuilder.ComponentRenderQueue.Count == 0) 778if (_batchBuilder.ComponentDisposalQueue.Count == 0) 792while (_batchBuilder.ComponentRenderQueue.Count > 0) 822if (_batchBuilder.ComponentRenderQueue.Count > 0) 967while (_batchBuilder.ComponentDisposalQueue.Count > 0)
Microsoft.AspNetCore.Components.WebAssembly (1)
Hosting\WebAssemblyCallQueue.cs (1)
24public static bool HasUnstartedWork => _pendingWork.Count > 0;
Microsoft.AspNetCore.Server.Kestrel.Core (1)
Internal\Http2\Http2FrameWriter.cs (1)
1128if (!_aborted && IsFlowControlQueueLimitEnabled && _waitingForMoreConnectionWindow.Count > _maximumFlowControlQueueSize)
Microsoft.AspNetCore.TestHost (1)
TestWebSocket.cs (1)
268if (_messageQueue.Count == 0)
Microsoft.Build (7)
BackEnd\Components\BuildRequestEngine\BuildRequestEngine.cs (1)
1041int countToSubmit = _unsubmittedRequests.Count;
BackEnd\Components\RequestBuilder\TargetBuilder.cs (1)
801while (targetsToCheckForAfterTargets?.Count > 0)
BackEnd\Components\Scheduler\Scheduler.cs (2)
1889while (_pendingRequestCoresCallbacks.Count > 0) 2645while (blockingRequests.Count > 0)
BuildCheck\Checks\NoEnvironmentVariablePropertyCheck.cs (1)
83while (_buildCheckResults.Count > 0)
Graph\ProjectGraph.cs (2)
572while (partialRoots.Count != 0) 708while (edgesToVisit.Count > 0)
Microsoft.Build.Tasks.CodeAnalysis (4)
Vbc.cs (4)
635if (_vbErrorLines.Count == 0 && 655if (_vbErrorLines.Count > 0) 662_numberOfLinesInErrorMessage = _vbErrorLines.Count; 675_vbErrorLines.Count == _numberOfLinesInErrorMessage + 3)
Microsoft.Cci.Extensions (2)
Extensions\CSharp\CSharpCciExtensions.cs (2)
144while (typesToCheck.Count != 0) 181while (typesToCheck.Count != 0)
Microsoft.CodeAnalysis (15)
DiagnosticAnalyzer\AsyncQueue.cs (6)
47return _data.Count; 92if (_waiters == null || _waiters.Count == 0) 98Debug.Assert(_data.Count == 0); 119if (_data.Count == 0) 188if (existingWaiters?.Count > 0) 268if (_data.Count > 0)
MetadataReader\MetadataDecoder.cs (2)
1988while ((hasMoreTypeDefs = (typeDefsToSearch.Count > 0)) || typeSymbolsToSearch.Count > 0)
PEWriter\MetadataWriter.cs (1)
509while (typesToIndex.Count > 0)
ReferenceManager\CommonReferenceManager.Binding.cs (1)
767while (match && candidatesToExamine.Count > 0)
Syntax\SyntaxDiffer.cs (5)
676if (first == null || first.Count == 0) 681if (next == null || next.Count == 0) 821if (queue == null || queue.Count == 0) 826var span = GetSpan(queue, 0, queue.Count); 838if (queue != null && queue.Count > 0)
Microsoft.CodeAnalysis.Analyzers (4)
MetaAnalyzers\DiagnosticAnalyzerAPIUsageAnalyzer.cs (2)
154} while (typesToProcess.Count != 0); 253} while (nodesToProcess.Count != 0);
src\RoslynAnalyzers\Utilities\Compiler\CodeMetrics\MetricsHelper.cs (1)
323} while (nodesToProcess.Count != 0);
src\RoslynAnalyzers\Utilities\Compiler\Extensions\IOperationExtensions.cs (1)
173while (operationsToProcess.Count > 0)
Microsoft.CodeAnalysis.AnalyzerUtilities (3)
src\RoslynAnalyzers\Utilities\Compiler\CodeMetrics\MetricsHelper.cs (1)
323} while (nodesToProcess.Count != 0);
src\RoslynAnalyzers\Utilities\Compiler\Extensions\IOperationExtensions.cs (1)
173while (operationsToProcess.Count > 0)
src\RoslynAnalyzers\Utilities\FlowAnalysis\FlowAnalysis\Analysis\GlobalFlowStateAnalysis\GlobalFlowStateAnalysis.GlobalFlowStateAnalysisValueSetDomain.cs (1)
169while (currentNodes.Count > 0)
Microsoft.CodeAnalysis.BannedApiAnalyzers (2)
src\RoslynAnalyzers\Utilities\Compiler\CodeMetrics\MetricsHelper.cs (1)
323} while (nodesToProcess.Count != 0);
src\RoslynAnalyzers\Utilities\Compiler\Extensions\IOperationExtensions.cs (1)
173while (operationsToProcess.Count > 0)
Microsoft.CodeAnalysis.CodeStyle (1)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\ObjectPools\Extensions.cs (1)
272var count = set.Count;
Microsoft.CodeAnalysis.CSharp.Symbol.UnitTests (1)
Symbols\CorLibrary\CorTypes.cs (1)
109while (namespaces.Count > 0)
Microsoft.CodeAnalysis.ExpressionEvaluator.ResultProvider.Utilities (2)
Debugger\Engine\DkmWorkList.cs (2)
47get { return _workList.Count; } 52while (_workList.Count > 0)
Microsoft.CodeAnalysis.ResxSourceGenerator (2)
src\RoslynAnalyzers\Utilities\Compiler\CodeMetrics\MetricsHelper.cs (1)
323} while (nodesToProcess.Count != 0);
src\RoslynAnalyzers\Utilities\Compiler\Extensions\IOperationExtensions.cs (1)
173while (operationsToProcess.Count > 0)
Microsoft.CodeAnalysis.Test.Utilities (1)
CompilationVerifier.cs (1)
991while (toVisit.Count > 0)
Microsoft.CodeAnalysis.UnitTests (2)
Collections\List\TestBase.Generic.cs (2)
154while (queue.Count < count) 165Debug.Assert(queue.Count == count);
Microsoft.CodeAnalysis.VisualBasic (2)
Binding\Binder_Lookup.vb (2)
1539Loop While lookIn.Count <> 0 2032Loop While lookIn.Count <> 0
Microsoft.CodeAnalysis.Workspaces (3)
Differencing\EditScript.cs (1)
67while (queue.Count > 0);
Shared\Extensions\INamespaceSymbolExtensions.cs (1)
178while (namespaceQueue.Count > 0)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\ObjectPools\Extensions.cs (1)
272var count = set.Count;
Microsoft.CodeAnalysis.Workspaces.MSBuild.BuildHost (1)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\ObjectPools\Extensions.cs (1)
272var count = set.Count;
Microsoft.DotNet.AsmDiff (2)
AssemblySet.cs (2)
58while (queue.Count > 0) 161while (queue.Count > 0)
Microsoft.DotNet.Build.Tasks.Packaging (1)
CreateTrimDependencyGroups.cs (1)
102int groupsToCheck = newDependencyGroups.Count;
Microsoft.Extensions.Http.Diagnostics (2)
Http\DownstreamDependencyMetadataManager.cs (2)
194while (queue.Count > 0) 229while (queue.Count > 0)
Microsoft.Extensions.Logging.Console (6)
ConsoleLoggerProcessor.cs (6)
114while (_messageQueue.Count >= MaxQueueLength && !_isAddingCompleted) 128Debug.Assert(_messageQueue.Count < MaxQueueLength); 129bool startedEmpty = _messageQueue.Count == 0; 163while (_messageQueue.Count == 0 && !_isAddingCompleted) 168if (_messageQueue.Count > 0) 171if (_messageQueue.Count == MaxQueueLength - 1)
Microsoft.Maui.Controls (7)
BindableObject.cs (1)
596 while (delayQueue.Count > 0)
Element\Element.cs (2)
703 while (queue.Count > 0) 809 while (queue.Count > 0)
LockingSemaphore.cs (1)
27 if (_waiters.Count > 0)
StyleSheets\CssReader.cs (2)
26 if (_cache.Count > 0) 64 if (_cache.Count > 0)
TemplateUtilities.cs (1)
90 while (queue.Count > 0)
Microsoft.Maui.Essentials (2)
Compass\LowPassFilter.shared.cs (2)
22 if (history.Count > length) 34 var size = history.Count;
Microsoft.ML.AutoML (2)
Tuner\SmacTuner.cs (2)
97var trialCount = _histories.Count + _candidates.Count; 104if (_candidates.Count <= 0)
Microsoft.ML.Core (5)
Data\Repository.cs (2)
355while (_closed.Count > 0) 386while (_closed.Count > 0)
Utilities\ThreadUtils.cs (3)
112if (_queue.Count <= _availableThreads) 135while (_queue.Count == 0) 139if (_queue.Count > 0)
Microsoft.ML.Core.Tests (1)
UnitTests\TestHosts.cs (1)
78while (queue.Count > 0)
Microsoft.ML.FastTree (3)
Training\EarlyStoppingCriteria.cs (3)
239Contracts.Assert(recentScores.Count > 0); 240return avg / recentScores.Count; 262if (PastScores.Count >= windowSize)
Microsoft.ML.StandardTrainers (1)
Optimizer\OptimizationMonitor.cs (1)
243if (_pastValues.Count < _n)
Microsoft.ML.Sweeper (2)
Algorithms\NelderMead.cs (2)
282Contracts.Assert(_pendingSweeps.Count + _pendingSweepsNotSubmitted.Count == _dim); 419int numPoints = Math.Min(maxSweeps, _pendingSweepsNotSubmitted.Count);
Microsoft.ML.Transforms (1)
Expression\Lexer.cs (1)
142while (_queue.Count == 0)
Microsoft.VisualStudio.LanguageServices (1)
Utilities\AutomationDelegatingListView.cs (1)
50while (peersToProcess.Count > 0)
MSBuild (2)
OutOfProcTaskHostNode.cs (2)
670int packetCount = _receivedPackets.Count; 676if (_receivedPackets.Count > 0)
MSBuildTaskHost (2)
OutOfProcTaskHostNode.cs (2)
670int packetCount = _receivedPackets.Count; 676if (_receivedPackets.Count > 0)
PresentationCore (7)
System\Windows\Input\Stylus\Common\DynamicRenderer.cs (2)
609if (_renderCompleteDRThreadStrokeInfoList.Count > 0) 616if (_renderCompleteDRThreadStrokeInfoList.Count == 0)
System\Windows\Input\Stylus\Wisp\WispLogic.cs (1)
316if (_queueStylusEvents.Count > 0)
System\Windows\Media\Animation\TimeManager.cs (1)
613while (_eventQueue.Count > 0)
System\Windows\Media\ChannelManager.cs (3)
75while (_freeSyncChannels.Count > 0) 139if (_freeSyncChannels.Count > 0) 189if (_freeSyncChannels.Count <= 3)
PresentationFramework (3)
MS\Internal\Data\DataBindEngine.cs (2)
529if (_crossThreadQueue.Count > 0) 556if (_crossThreadQueue.Count > 0)
System\Windows\Controls\ItemContainerGenerator.cs (1)
1400if (_factory._recyclableContainers.Count > 0 && !_factory.Host.IsItemItsOwnContainer(item) && !isNewItemPlaceHolderWhenGrouping)
Roslyn.Diagnostics.Analyzers (2)
src\RoslynAnalyzers\Utilities\Compiler\CodeMetrics\MetricsHelper.cs (1)
323} while (nodesToProcess.Count != 0);
src\RoslynAnalyzers\Utilities\Compiler\Extensions\IOperationExtensions.cs (1)
173while (operationsToProcess.Count > 0)
RunTests (1)
ProcessUtil.cs (1)
78while (toVisit.Count > 0)
System.CodeDom (3)
src\libraries\Common\src\System\CodeDom\CodeTypeReference.cs (3)
232if (q.Count > 0) 241while (q.Count > 1) 247Debug.Assert(q.Count == 1, "We should have one and only one in the rank queue.");
System.Collections (2)
System\Collections\Generic\SortedSet.cs (1)
241while (processQueue.Count != 0)
System\Collections\Generic\SortedSet.TreeSubSet.cs (1)
257while (processQueue.Count != 0)
System.ComponentModel.Composition (3)
System\ComponentModel\Composition\ContractNameServices.cs (3)
130if (genericTypeArguments.Count != 0) 268if (genericTypeArguments.Count == 0) 305if (typeArguments.Count != 0)
System.Composition.Hosting (2)
System\Composition\Hosting\Core\UpdateResult.cs (2)
27if (_remainingProviders.Count == 0) 47if (_remainingProviders.Count != 0)
System.Diagnostics.Process (1)
System\Diagnostics\AsyncStreamReader.cs (1)
228if (_messageQueue.Count == 0)
System.IO.Ports (2)
System\IO\Ports\SerialStream.Unix.cs (2)
1031return _readQueue.Count == 0; 1039return _writeQueue.Count == 0;
System.Linq (5)
System\Linq\ElementAt.cs (2)
164if (queue.Count == indexFromEnd) 172if (queue.Count == indexFromEnd)
System\Linq\Take.cs (3)
144Debug.Assert(queue.Count == Math.Min(count, startIndex)); 149Debug.Assert(endIndex - startIndex <= queue.Count); 174if (queue.Count == endIndex)
System.Linq.AsyncEnumerable (5)
System\Linq\ElementAtAsync.cs (2)
152if (queue.Count == indexFromEnd) 160if (queue.Count == indexFromEnd)
System\Linq\Take.cs (3)
173Debug.Assert(queue.Count == Math.Min(count, startIndex)); 178Debug.Assert(endIndex - startIndex <= queue.Count); 203if (queue.Count == endIndex)
System.Linq.Expressions (1)
System\Linq\Expressions\DebugViewWriter.cs (1)
141while (_lambdas != null && _lambdas.Count > 0)
System.Linq.Parallel (8)
System\Linq\Parallel\Channels\SynchronousChannel.cs (1)
133return _queue.Count;
System\Linq\Parallel\Merging\OrderPreservingPipeliningMergeHelper.cs (6)
397if (buffer.Count == 0) 413if (buffer.Count == 0) 421Debug.Assert(buffer.Count > 0, "Producer's buffer should not be empty here."); 432if (buffer.Count < STEAL_BUFFER_SIZE) 465if (privateChunk.Count > 0) 471Debug.Assert(_privateBuffer[producer]!.Count == 0);
System\Linq\Parallel\Scheduling\OrderPreservingPipeliningSpoolingTask.cs (1)
134if (_buffers[_partitionIndex].Count >= OrderPreservingPipeliningMergeHelper<TOutput, TKey>.MAX_BUFFER_SIZE)
System.Private.CoreLib (3)
src\libraries\System.Private.CoreLib\src\System\Collections\Generic\Queue.cs (1)
186Count == 0 ? SZGenericArrayEnumerator<T>.Empty :
src\libraries\System.Private.CoreLib\src\System\IO\Enumeration\FileSystemEnumerator.Unix.cs (1)
221if (_pending == null || _pending.Count == 0)
src\libraries\System.Private.CoreLib\src\System\Threading\Tasks\Task.cs (1)
6923if (Count == 1)
System.Private.DataContractSerialization (5)
src\libraries\Common\src\System\CodeDom\CodeTypeReference.cs (3)
232if (q.Count > 0) 241while (q.Count > 1) 247Debug.Assert(q.Count == 1, "We should have one and only one in the rank queue.");
System\Runtime\Serialization\DataContract.cs (1)
1140while (itemTypeQueue.Count > 0)
System\Runtime\Serialization\ExtensionDataReader.cs (1)
72IDataNode? deserializedDataNode = (_deserializedDataNodes == null || _deserializedDataNodes.Count == 0) ? null : _deserializedDataNodes.Dequeue();
System.Private.Windows.Core (4)
System\Private\Windows\BinaryFormat\Deserializer\Deserializer.cs (4)
133int pendingCount = _pendingSerializationInfo?.Count ?? 0; 134while (_pendingSerializationInfo is not null && _pendingSerializationInfo.Count > 0) 140&& _pendingSerializationInfo.Count != 0 310while (_pendingCompletions.Count > 0)
System.Private.Xml (2)
System\Xml\Schema\ContentValidator.cs (1)
1460while (unmarked.Count > 0)
System\Xml\Serialization\CodeGenerator.cs (1)
231if (freeLocalQueue.Count == 0)
System.Resources.Extensions (4)
System\Resources\Extensions\BinaryFormat\Deserializer\Deserializer.cs (4)
138int pendingCount = _pendingSerializationInfo?.Count ?? 0; 139while (_pendingSerializationInfo is not null && _pendingSerializationInfo.Count > 0) 145&& _pendingSerializationInfo.Count != 0 315while (_pendingCompletions.Count > 0)
System.Text.Json (3)
src\libraries\System.Text.Json\Common\JsonHelpers.cs (2)
144Debug.Assert(childlessQueue.Count > 0, "The graph contains cycles."); 170} while (childlessQueue.Count > 0);
System\Text\Json\ValueQueue.cs (1)
21public readonly int Count => _state < 2 ? _state : _multiple!.Count;
System.Text.Json.SourceGeneration (5)
JsonSourceGenerator.Parser.cs (2)
88Debug.Assert(_typesToGenerate.Count == 0); 140while (_typesToGenerate.Count > 0)
src\libraries\System.Text.Json\Common\JsonHelpers.cs (3)
34if (queue.Count > 0) 144Debug.Assert(childlessQueue.Count > 0, "The graph contains cycles."); 170} while (childlessQueue.Count > 0);
System.Text.RegularExpressions (3)
System\Text\RegularExpressions\Symbolic\SymbolicRegexMatcher.Explore.cs (3)
34while (toExplore.Count > 0) 60if (exploreNfa && toExplore.Count > 0) 78while (toExplore.Count > 0)
System.Threading.Tasks.Dataflow (27)
Blocks\BatchBlock.cs (12)
392(_batchesCompleted + (_messages.Count / _batchSize)) >= _dataflowBlockOptions.ActualMaxNumberOfGroups) 506bool noMoreMessages = _decliningPermanently && _messages.Count < _batchSize; 517if (_messages.Count > 0) MakeBatchIfPossible(evenIfFewerThanBatchSize: true); 571int neededMessageCountToCompleteBatch = _batchSize - _messages.Count; 580if (_nonGreedyState.AcceptFewerThanBatchSize && _messages.Count > 0) 646_messages.Count + _nonGreedyState.PostponedMessages.Count); 732bool fullBatch = _messages.Count >= _batchSize; 735if (fullBatch || (evenIfFewerThanBatchSize && _messages.Count > 0)) 737var newBatch = new T[fullBatch ? _batchSize : _messages.Count]; 770Debug.Assert(_messages.Count == 0, "The queue must be empty between batches in non-greedy mode"); 890itemCountNeededToCompleteBatch = _batchSize - _messages.Count; 1150private int InputCountForDebugger { get { return _messages.Count; } }
Blocks\BroadcastBlock.cs (9)
623if (_messages.Count == 1) _enableOffering = true; 724if (_nextMessageReservedFor == null && _messages.Count > 0) 730while (_messages.Count > 1) 738Debug.Assert(_messages.Count > 0, "There must be at least one message to dequeue."); 743if (_messages.Count == 0) _enableOffering = false; 824bool processingToDo = _enableOffering && _messages.Count > 0; 838_owningSource, _taskForOutputProcessing, DataflowEtwProvider.TaskLaunchedReason.OfferingOutputMessages, _messages.Count); 921bool noMoreMessages = _decliningPermanently && _messages.Count == 0; 940(_decliningPermanently && _messages.Count == 0) || CanceledOrFaulted,
Blocks\JoinBlock.cs (6)
519Debug.Assert(_messages.Count >= 0, "A message must have been consumed by this point."); 550return _messages.Count > 0; 575return !_sharedResources._dataflowBlockOptions.Greedy ? _nonGreedy!.PostponedMessages.Count : _messages!.Count; 588int count = _messages!.Count; 730_messages!.Count : 938private int InputCountForDebugger { get { return _messages != null ? _messages.Count : _nonGreedy!.ConsumedMessage.Key ? 1 : 0; } }
System.Windows.Forms (16)
System\Windows\Forms\Control.cs (5)
3502if (IsDisposed && _threadCallbackList is not null && _threadCallbackList.Count > 0) 3507while (_threadCallbackList.Count > 0) 4656while (_threadCallbackList.Count > 0) 6106if (_threadCallbackList.Count > 0) 6159current = _threadCallbackList.Count > 0 ? _threadCallbackList.Dequeue() : null;
System\Windows\Forms\Dialogs\TaskDialog\TaskDialog.cs (4)
944if (_waitingNavigationPages.Count == 0 && !_raisedPageCreated) 962if (_waitingNavigationPages.Count == 0) 1323int originalCount = _waitingNavigationPages.Count; 1639if (_waitingNavigationPages.Count > 0 && checkWaitingForNavigation)
System\Windows\Forms\SendKeys\SendKeys.cs (4)
670eventsTotal = s_events.Count; 917if (s_events.Count != 0) 926if (s_events.Count == 0) 992while (s_events.Count > 0)
System\Windows\Forms\SendKeys\SendKeys.SendKeysHookProc.cs (3)
40if (s_events.Count > 0) 45s_stopHook = s_events.Count == 0; 54s_events.Count > 0 && !s_stopHook,
System.Windows.Input.Manipulations (14)
System\Windows\Input\Manipulations\ManipulationSequence.cs (14)
204ManipulationState firstSample = this.history.Count > 0 ? this.history.Peek() : default(ManipulationState); 227if (this.smoothing.Count > 1) 243if (this.smoothing.Count > 1) 259if (this.smoothing.Count > 1) 397if (this.processorState != ProcessorState.Waiting && currentManipulatorCount > 0 && this.history.Count > 0) 732if (this.history.Count == 0) 1076int count = queue.Count; 1137int count = queue.Count; 1287if (Count >= MaxHistoryLength) 1293while (Count > 0) 1356while (Count > this.historyLength) 1393if (Count == 0) 1409if (Count >= this.historyLength) 1416while (Count > 0)
System.Xaml (9)
System\Xaml\Context\NameFixupGraph.cs (1)
220get { return _resolvedTokensPendingProcessing.Count > 0; }
System\Xaml\Parser\NodeStreamSorter.cs (2)
119if (_buffer.Count > 0) 421_moveList.Add(_buffer.Count); // mark the current position as needing fixup
System\Xaml\Parser\XamlScanner.cs (2)
152if (_readNodesQueue.Count == 0) 160while (_readNodesQueue.Count == 0)
System\Xaml\XamlNodeQueue.cs (3)
50get { return _nodeQueue.Count == 0; } 55get { return _nodeQueue.Count; } 92if (_nodeQueue.Count > 0)
System\Xaml\XamlObjectReader.cs (1)
59while (context.PendingNameScopes.Count > 0)
Test.Utilities (1)
src\RoslynAnalyzers\Utilities\Compiler\Extensions\IOperationExtensions.cs (1)
173while (operationsToProcess.Count > 0)
Text.Analyzers (2)
src\RoslynAnalyzers\Utilities\Compiler\CodeMetrics\MetricsHelper.cs (1)
323} while (nodesToProcess.Count != 0);
src\RoslynAnalyzers\Utilities\Compiler\Extensions\IOperationExtensions.cs (1)
173while (operationsToProcess.Count > 0)
VBCSCompiler.UnitTests (1)
TestableClientConnectionHost.cs (1)
50if (_waitingTasks.Count == 0)