Suggested API's for "System.Collections."
System.Collections.ArrayList.Adapter(System.Collections.IList)System.Collections.ArrayList.Add(object)System.Collections.ArrayList.Add(System.Object)System.Collections.ArrayList.AddRange(System.Collections.ICollection)System.Collections.ArrayList.BinarySearch(int, int, object, System.Collections.IComparer)System.Collections.ArrayList.BinarySearch(int, int, System.Object, System.Collections.IComparer)System.Collections.ArrayList.BinarySearch(object)System.Collections.ArrayList.BinarySearch(object, System.Collections.IComparer)System.Collections.ArrayList.BinarySearch(System.Object)System.Collections.ArrayList.BinarySearch(System.Object, System.Collections.IComparer)System.Collections.ArrayList.Clear()System.Collections.ArrayList.Clone()System.Collections.ArrayList.Contains(object)System.Collections.ArrayList.Contains(System.Object)System.Collections.ArrayList.CopyTo(int, System.Array, int, int)System.Collections.ArrayList.CopyTo(System.Array)System.Collections.ArrayList.CopyTo(System.Array, int)System.Collections.ArrayList.EnsureCapacity(int)System.Collections.ArrayList.GetEnumerator()System.Collections.ArrayList.GetEnumerator(int, int)System.Collections.ArrayList.GetRange(int, int)System.Collections.ArrayList.IListWrapper.CopyTo(int, System.Array, int, int)System.Collections.ArrayList.IListWrapper.IndexOf(object)System.Collections.ArrayList.IListWrapper.IndexOf(object, int, int)System.Collections.ArrayList.IListWrapper.IndexOf(System.Object)System.Collections.ArrayList.IListWrapper.IndexOf(System.Object, int, int)System.Collections.ArrayList.IListWrapper.InsertRange(int, System.Collections.ICollection)System.Collections.ArrayList.IListWrapper.LastIndexOf(object, int, int)System.Collections.ArrayList.IListWrapper.LastIndexOf(System.Object, int, int)System.Collections.ArrayList.IListWrapper.RemoveAt(int)System.Collections.ArrayList.IndexOf(object)System.Collections.ArrayList.IndexOf(object, int)System.Collections.ArrayList.IndexOf(object, int, int)System.Collections.ArrayList.IndexOf(System.Object)System.Collections.ArrayList.IndexOf(System.Object, int)System.Collections.ArrayList.IndexOf(System.Object, int, int)System.Collections.ArrayList.Insert(int, object)System.Collections.ArrayList.Insert(int, System.Object)System.Collections.ArrayList.InsertRange(int, System.Collections.ICollection)System.Collections.ArrayList.LastIndexOf(object)System.Collections.ArrayList.LastIndexOf(object, int)System.Collections.ArrayList.LastIndexOf(object, int, int)System.Collections.ArrayList.LastIndexOf(System.Object)System.Collections.ArrayList.LastIndexOf(System.Object, int)System.Collections.ArrayList.LastIndexOf(System.Object, int, int)System.Collections.ArrayList.Pop()System.Collections.ArrayList.Push(object)System.Collections.ArrayList.Range.GetEnumerator(int, int)System.Collections.ArrayList.Range.InternalUpdateRange()System.Collections.ArrayList.Range.InternalUpdateVersion()System.Collections.ArrayList.Range.LastIndexOf(object, int, int)System.Collections.ArrayList.Range.LastIndexOf(System.Object, int, int)System.Collections.ArrayList.ReadOnly(System.Collections.ArrayList)System.Collections.ArrayList.ReadOnly(System.Collections.IList)System.Collections.ArrayList.Remove(object)System.Collections.ArrayList.Remove(System.Object)System.Collections.ArrayList.RemoveAt(int)System.Collections.ArrayList.RemoveRange(int, int)System.Collections.ArrayList.Repeat(object, int)System.Collections.ArrayList.Reverse()System.Collections.ArrayList.Reverse(int, int)System.Collections.ArrayList.SetRange(int, System.Collections.ICollection)System.Collections.ArrayList.ShouldNotBeNull()System.Collections.ArrayList.Sort()System.Collections.ArrayList.Sort(int, int, System.Collections.IComparer)System.Collections.ArrayList.Sort(System.Collections.IComparer)System.Collections.ArrayList.Synchronized(System.Collections.ArrayList)System.Collections.ArrayList.Synchronized(System.Collections.IList)System.Collections.ArrayList.ToArray()System.Collections.ArrayList.ToArray(System.Type)System.Collections.ArrayList.TrimToSize()System.Collections.ArrayList.UnwrapListOrArray(System.Collections.IList)System.Collections.Async.AsyncEnumerable.GetAsyncEnumeratorAsync(System.Threading.CancellationToken)System.Collections.Async.AsyncEnumerator.Yield.OnMoveNext(System.Threading.CancellationToken)System.Collections.Async.AsyncEnumerator.Yield.SetCanceled()System.Collections.Async.AsyncEnumerator.Yield.SetComplete()System.Collections.Async.AsyncEnumerator.Yield.SetFailed(System.Exception)System.Collections.Async.AsyncEnumeratorWithState.Dispose(bool)System.Collections.Async.IAsyncEnumerableExtensions.Batch(IAsyncEnumerable, int)System.Collections.Async.IAsyncEnumerableExtensions.Batch(IAsyncEnumerable, int, long, System.Func)System.Collections.Async.IAsyncEnumerableExtensions.Batch(IAsyncEnumerable, int, long, System.Func, System.Func, System.Action)System.Collections.Async.IAsyncEnumerableExtensions.Batch(IAsyncEnumerable, long, System.Func)System.Collections.Async.IAsyncEnumerableExtensions.BatchCollectionHelper.GetAddToCollectionAction()System.Collections.Async.IAsyncEnumerableExtensions.BatchCollectionHelper.GetCreateCollectionFunction()System.Collections.Async.IAsyncEnumerableExtensions.DefaultIfEmpty(IAsyncEnumerable, TSource)System.Collections.Async.IAsyncEnumerableExtensions.FirstAsync(IAsyncEnumerable, System.Func, string, System.Threading.CancellationToken)System.Collections.Async.IAsyncEnumerableExtensions.FirstOrDefaultAsync(IAsyncEnumerable, System.Func, System.Threading.CancellationToken)System.Collections.Async.IAsyncEnumerableExtensions.SingleAsync(IAsyncEnumerable, System.Func, string, string, System.Threading.CancellationToken)System.Collections.Async.IAsyncEnumerableExtensions.SingleOrDefaultAsync(IAsyncEnumerable, System.Func, System.Threading.CancellationToken)System.Collections.Async.IAsyncEnumeratorExtensions.Batch(IAsyncEnumerator, int, bool)System.Collections.Async.IAsyncEnumeratorExtensions.Batch(IAsyncEnumerator, int, long, System.Func, bool)System.Collections.Async.IAsyncEnumeratorExtensions.Batch(IAsyncEnumerator, int, long, System.Func, System.Func, System.Action, bool)System.Collections.Async.IAsyncEnumeratorExtensions.Batch(IAsyncEnumerator, long, System.Func, bool)System.Collections.Async.IAsyncEnumeratorExtensions.DefaultIfEmpty(IAsyncEnumerator, TSource, bool)System.Collections.Async.IAsyncEnumeratorExtensions.FirstAsync(IAsyncEnumerator, System.Func, string, System.Threading.CancellationToken, bool)System.Collections.Async.IAsyncEnumeratorExtensions.FirstOrDefaultAsync(IAsyncEnumerator, System.Func, System.Threading.CancellationToken, bool)System.Collections.Async.IAsyncEnumeratorExtensions.SingleAsync(IAsyncEnumerator, System.Func, string, string, System.Threading.CancellationToken, bool)System.Collections.Async.IAsyncEnumeratorExtensions.SingleOrDefaultAsync(IAsyncEnumerator, System.Func, System.Threading.CancellationToken, bool)System.Collections.Async.Internals.AsyncEnumerableWrapper.CreateAsyncEnumerator()System.Collections.Async.Internals.EnumerableAdapter.GetEnumerator()System.Collections.Async.ParallelForEachExtensions.ParallelForEachContext.AddException(System.Exception)System.Collections.Async.ParallelForEachExtensions.ParallelForEachContext.CompleteLoopNow()System.Collections.Async.ParallelForEachExtensions.ParallelForEachContext.OnOperationComplete(System.Exception)System.Collections.Async.ParallelForEachExtensions.ParallelForEachContext.OnStartOperationAsync(System.Threading.CancellationToken)System.Collections.Async.ParallelForEachExtensions.ParallelForEachContext.ReadExceptions()System.Collections.AutoFlushContainer.Flush()System.Collections.AutoFlushContainer.FlushDelegate.Invoke(T, bool)System.Collections.BitArray.AddBits(ref int, int, int)System.Collections.BitArray.And(System.Collections.BitArray)System.Collections.BitArray.AndNot(System.Collections.BitArray)System.Collections.BitArray.BitArrayEnumerator.checkVersion()System.Collections.BitArray.Cardinality()System.Collections.BitArray.checkOperand(System.Collections.BitArray)System.Collections.BitArray.Clone()System.Collections.BitArray.CopyTo(System.Array, int)System.Collections.BitArray.Get(int)System.Collections.BitArray.GetArrayLength(int, int)System.Collections.BitArray.GetBits(ref int, int)System.Collections.BitArray.getByte(int)System.Collections.BitArray.GetEnumerator()System.Collections.BitArray.GetInt()System.Collections.BitArray.GetNumeral(int, int)System.Collections.BitArray.MapIndex(int)System.Collections.BitArray.NextSetBit(int)System.Collections.BitArray.Not()System.Collections.BitArray.Or(System.Collections.BitArray)System.Collections.BitArray.Set(int, bool)System.Collections.BitArray.SetAll(bool)System.Collections.BitArray.ToNumeral()System.Collections.BitArray.TrueCount()System.Collections.BitArray.Xor(System.Collections.BitArray)System.Collections.BitSet.Get(int)System.Collections.BitSet.GetArrayLength(int, int)System.Collections.CaseInsensitiveComparer.Compare(object, object)System.Collections.CollectionBase.Clear()System.Collections.CollectionBase.GetEnumerator()System.Collections.CollectionBase.OnClear()System.Collections.CollectionBase.OnClearComplete()System.Collections.CollectionBase.OnInsert(int, object)System.Collections.CollectionBase.OnInsert(int, System.Object)System.Collections.CollectionBase.OnInsertComplete(int, object)System.Collections.CollectionBase.OnInsertComplete(int, System.Object)System.Collections.CollectionBase.OnRemove(int, object)System.Collections.CollectionBase.OnRemove(int, System.Object)System.Collections.CollectionBase.OnRemoveComplete(int, object)System.Collections.CollectionBase.OnRemoveComplete(int, System.Object)System.Collections.CollectionBase.OnSet(int, object, object)System.Collections.CollectionBase.OnSetComplete(int, object, object)System.Collections.CollectionBase.OnValidate(object)System.Collections.CollectionBase.OnValidate(System.Object)System.Collections.CollectionBase.RemoveAt(int)System.Collections.Comparer.Compare(object, object)System.Collections.CompatibleComparer.Compare(object, object)System.Collections.CompatibleComparer.Compare(System.Object, System.Object)System.Collections.Concurrent.BlockingCollection.Add((RequestProcessType type, string name, System.Func request))System.Collections.Concurrent.BlockingCollection.Add((System.Action, System.Threading.Tasks.TaskCompletionSource))System.Collections.Concurrent.BlockingCollection.Add((System.Threading.SendOrPostCallback callback, object state))System.Collections.Concurrent.BlockingCollection.Add(Abc.Zebus.Transport.ZmqTransport.OutboundSocketAction)System.Collections.Concurrent.BlockingCollection.Add(Akavache.Sqlite3.OperationQueueItem)System.Collections.Concurrent.BlockingCollection.Add(AvsAnSighting[], System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(BaseData, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(BasicDeliverEventArgs)System.Collections.Concurrent.BlockingCollection.Add(BasicDeliverEventArgs, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(Battle.Actor.EvtBase, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(BCCSpliter.Logging.LogMessageEntry)System.Collections.Concurrent.BlockingCollection.Add(bool, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(BrokeredMessage)System.Collections.Concurrent.BlockingCollection.Add(BTCPayServer.Logging.LogMessageEntry)System.Collections.Concurrent.BlockingCollection.Add(BuildEventArgs, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(ByteBuf, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(byte[])System.Collections.Concurrent.BlockingCollection.Add(byte[], System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(CallbackRegistration)System.Collections.Concurrent.BlockingCollection.Add(Cassette.Scripts.IECoffeeScriptCompilationQueue.CompileTask)System.Collections.Concurrent.BlockingCollection.Add(CciModuleSource)System.Collections.Concurrent.BlockingCollection.Add(Chapter6.Recipe5.Program.CustomTask)System.Collections.Concurrent.BlockingCollection.Add(ChunkContext)System.Collections.Concurrent.BlockingCollection.Add(ClearScript.Manager.IRuntimeManager)System.Collections.Concurrent.BlockingCollection.Add(CommandModel)System.Collections.Concurrent.BlockingCollection.Add(CommandModel, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(CommandResult)System.Collections.Concurrent.BlockingCollection.Add(Common.IO.Sequencing.BgzfWriterCommon.CompressedData)System.Collections.Concurrent.BlockingCollection.Add(Common.IO.Sequencing.BgzfWriterCommon.Data)System.Collections.Concurrent.BlockingCollection.Add(CompletionStatus)System.Collections.Concurrent.BlockingCollection.Add(ConnectionStateChangedEventArgs, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(DataSlice)System.Collections.Concurrent.BlockingCollection.Add(DeBruijnNode)System.Collections.Concurrent.BlockingCollection.Add(DistributedAppMessage, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(DomainEventHandledMessage)System.Collections.Concurrent.BlockingCollection.Add(DotNetty.Common.PreciseTimeSpan, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(DumpWriter.DumpWriter.DumpedSegment)System.Collections.Concurrent.BlockingCollection.Add(EDDiscovery.StarGrid)System.Collections.Concurrent.BlockingCollection.Add(EQueue.Broker.LongPolling.SuspendedPullRequestManager.NotifyItem)System.Collections.Concurrent.BlockingCollection.Add(EQueue.Clients.Consumers.ConsumingMessage)System.Collections.Concurrent.BlockingCollection.Add(EQueue.Clients.Consumers.ConsumingMessage, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(EQueue.Protocols.Message, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(EQueue.Protocols.QueueMessage, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(Event)System.Collections.Concurrent.BlockingCollection.Add(EventData)System.Collections.Concurrent.BlockingCollection.Add(FastFetch.Git.GitIndexGenerator.LsTreeEntry, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(FetchedDataChunk)System.Collections.Concurrent.BlockingCollection.Add(FetchedDataChunk, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(FileChange)System.Collections.Concurrent.BlockingCollection.Add(FileEvent, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(float[])System.Collections.Concurrent.BlockingCollection.Add(GelfMessage, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(Google.Apis.Storage.v1.Data.Bucket)System.Collections.Concurrent.BlockingCollection.Add(HttpResponse)System.Collections.Concurrent.BlockingCollection.Add(HybrasylMessage, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(IBucketConfig)System.Collections.Concurrent.BlockingCollection.Add(ICommit)System.Collections.Concurrent.BlockingCollection.Add(IConversion)System.Collections.Concurrent.BlockingCollection.Add(IDelivery)System.Collections.Concurrent.BlockingCollection.Add(IEvent)System.Collections.Concurrent.BlockingCollection.Add(IMailboxProcessorCommand, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(IMemcacheRequest)System.Collections.Concurrent.BlockingCollection.Add(IMemcacheTransport)System.Collections.Concurrent.BlockingCollection.Add(IMessage)System.Collections.Concurrent.BlockingCollection.Add(IMessage, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(IMessageContext, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(IndexPackRequest, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(InfluxData.Net.InfluxDb.Models.Point)System.Collections.Concurrent.BlockingCollection.Add(INode)System.Collections.Concurrent.BlockingCollection.Add(InProcSocketPair)System.Collections.Concurrent.BlockingCollection.Add(int)System.Collections.Concurrent.BlockingCollection.Add(int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(IParallelRunnerWorkItem)System.Collections.Concurrent.BlockingCollection.Add(IParallelRunnerWorkItem, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(IPDiscoveryEventArgs)System.Collections.Concurrent.BlockingCollection.Add(IPooledConnection)System.Collections.Concurrent.BlockingCollection.Add(IQQActor)System.Collections.Concurrent.BlockingCollection.Add(IRenderEngine)System.Collections.Concurrent.BlockingCollection.Add(ISequence)System.Collections.Concurrent.BlockingCollection.Add(ISymmetricalCipher)System.Collections.Concurrent.BlockingCollection.Add(ISymmetricalCipher, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(ITransferController, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(Jackett.CurlHelper.CurlRequest)System.Collections.Concurrent.BlockingCollection.Add(JavaScriptValue)System.Collections.Concurrent.BlockingCollection.Add(Job, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(JournalEntry)System.Collections.Concurrent.BlockingCollection.Add(JsonFlatFileDataStore.DataStore.CommitAction)System.Collections.Concurrent.BlockingCollection.Add(KafkaRecord, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(KeyedMessage)System.Collections.Concurrent.BlockingCollection.Add(Kill, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(KnxDatagram)System.Collections.Concurrent.BlockingCollection.Add(LibRdKafka.PartitionerCallback)System.Collections.Concurrent.BlockingCollection.Add(Lime.Protocol.Command)System.Collections.Concurrent.BlockingCollection.Add(Lime.Protocol.Command, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(Lime.Protocol.Message)System.Collections.Concurrent.BlockingCollection.Add(Lime.Protocol.Message, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(Lime.Protocol.Notification)System.Collections.Concurrent.BlockingCollection.Add(Lime.Protocol.Notification, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(LogEvent)System.Collections.Concurrent.BlockingCollection.Add(LoggingEventContext, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(LogMessageEntry)System.Collections.Concurrent.BlockingCollection.Add(LogMessageEntry, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(long)System.Collections.Concurrent.BlockingCollection.Add(ManagedUPnP.Device)System.Collections.Concurrent.BlockingCollection.Add(Message)System.Collections.Concurrent.BlockingCollection.Add(Message, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(MessageContext)System.Collections.Concurrent.BlockingCollection.Add(MessageContext, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(MessageData)System.Collections.Concurrent.BlockingCollection.Add(MessageState)System.Collections.Concurrent.BlockingCollection.Add(MessageState, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(MetroFtpClient.Ftp.FtpClient.Download)System.Collections.Concurrent.BlockingCollection.Add(Microsoft.NodejsTools.NpmUI.NpmWorker.QueuedNpmCommandInfo, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(MqttApplicationMessage)System.Collections.Concurrent.BlockingCollection.Add(MqttApplicationMessage, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(MqttBasePacket)System.Collections.Concurrent.BlockingCollection.Add(MqttPublishPacket)System.Collections.Concurrent.BlockingCollection.Add(MqttPublishPacket, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(Msg)System.Collections.Concurrent.BlockingCollection.Add(MumbleSharp.Audio.AudioEncodingBuffer.TargettedSpeech)System.Collections.Concurrent.BlockingCollection.Add(NBitcoin.Protocol.Node.SentMessage)System.Collections.Concurrent.BlockingCollection.Add(NDomain.Bus.Transport.LocalMessage)System.Collections.Concurrent.BlockingCollection.Add(Network.Client.SynClient, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(NMaier.SimpleDlna.FileMediaServer.BackgroundCacher.Item)System.Collections.Concurrent.BlockingCollection.Add(NodeEvent)System.Collections.Concurrent.BlockingCollection.Add(Notification, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(NpgsqlConnection)System.Collections.Concurrent.BlockingCollection.Add(NpgsqlConnection, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(NTumbleBit.Logging.LogMessageEntry)System.Collections.Concurrent.BlockingCollection.Add(NuGet.Server.Infrastructure.Lucene.PackageIndexer.Update)System.Collections.Concurrent.BlockingCollection.Add(object)System.Collections.Concurrent.BlockingCollection.Add(object, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(OpenSim.Framework.Monitoring.JobEngine.Job)System.Collections.Concurrent.BlockingCollection.Add(Orleans.Membership.ServiceFabric.FabricMembershipOracle.StatusChangeNotification, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(Orleans.Runtime.QueuedExecutor.QueueWorkItemCallback, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(Orleans.Runtime.Scheduler.IWorkItem, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(OutgoingVoice)System.Collections.Concurrent.BlockingCollection.Add(Output)System.Collections.Concurrent.BlockingCollection.Add(Packet)System.Collections.Concurrent.BlockingCollection.Add(Pair)System.Collections.Concurrent.BlockingCollection.Add(Pair[])System.Collections.Concurrent.BlockingCollection.Add(PartitionSnapshot)System.Collections.Concurrent.BlockingCollection.Add(PendingPacket)System.Collections.Concurrent.BlockingCollection.Add(PersistentTable)System.Collections.Concurrent.BlockingCollection.Add(PingId, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(ProjectFilesClone)System.Collections.Concurrent.BlockingCollection.Add(QueuedCommand)System.Collections.Concurrent.BlockingCollection.Add(QueuedMemoryWriter)System.Collections.Concurrent.BlockingCollection.Add(RabbitMQ.Client.Events.BasicDeliverEventArgs, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(RabbitMQ.Client.IBasicConsumer, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(RabbitMQ.Client.IModel)System.Collections.Concurrent.BlockingCollection.Add(RecordedEvent)System.Collections.Concurrent.BlockingCollection.Add(RedditPost)System.Collections.Concurrent.BlockingCollection.Add(RemoteCall, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(RequestVoteResponse, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(ResponderWorkerWithState, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(ResultContainer)System.Collections.Concurrent.BlockingCollection.Add(Revenj.DomainPatterns.GlobalEventStore.EventInfo)System.Collections.Concurrent.BlockingCollection.Add(Revenj.Processing.Scope)System.Collections.Concurrent.BlockingCollection.Add(Row, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(S3ToAzureSample.S3ToAzureTransferJob, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(SaeaAwaitable)System.Collections.Concurrent.BlockingCollection.Add(SampleCollection)System.Collections.Concurrent.BlockingCollection.Add(SassyStudio.Compiler.BackgroundParsingTask.BackgroundParseRequest)System.Collections.Concurrent.BlockingCollection.Add(Serilog.Events.LogEvent)System.Collections.Concurrent.BlockingCollection.Add(ServiceOwnerChangedEventArgs)System.Collections.Concurrent.BlockingCollection.Add(SimpleTask)System.Collections.Concurrent.BlockingCollection.Add(SimpleTester.EventStorageSpeedTest.ValueEvent)System.Collections.Concurrent.BlockingCollection.Add(Span)System.Collections.Concurrent.BlockingCollection.Add(Spring.Messaging.Amqp.Rabbit.Listener.Delivery)System.Collections.Concurrent.BlockingCollection.Add(StackExchange.Precompilation.RazorParser.RazorTextLoader, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(Stanza, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(Steam_Library_Manager.Functions.Logger.AppLog)System.Collections.Concurrent.BlockingCollection.Add(Stratis.Bitcoin.P2P.Peer.SentMessage)System.Collections.Concurrent.BlockingCollection.Add(string)System.Collections.Concurrent.BlockingCollection.Add(string, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(string[])System.Collections.Concurrent.BlockingCollection.Add(STSdb4.General.Communication.Packet)System.Collections.Concurrent.BlockingCollection.Add(STSdb4.General.Communication.Packet, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(System.Action)System.Collections.Concurrent.BlockingCollection.Add(System.Action, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(System.Collections.Generic.IList, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(System.Collections.Generic.KeyValuePair)System.Collections.Concurrent.BlockingCollection.Add(System.Collections.Generic.KeyValuePair, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(System.Collections.Generic.List)System.Collections.Concurrent.BlockingCollection.Add(System.ConsoleKeyInfo)System.Collections.Concurrent.BlockingCollection.Add(System.Diagnostics.Stopwatch)System.Collections.Concurrent.BlockingCollection.Add(System.Drawing.Bitmap)System.Collections.Concurrent.BlockingCollection.Add(System.Drawing.Image)System.Collections.Concurrent.BlockingCollection.Add(System.Drawing.Point)System.Collections.Concurrent.BlockingCollection.Add(System.Exception)System.Collections.Concurrent.BlockingCollection.Add(System.Func, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(System.Guid)System.Collections.Concurrent.BlockingCollection.Add(System.IDisposable)System.Collections.Concurrent.BlockingCollection.Add(System.IO.FileSystemEventArgs)System.Collections.Concurrent.BlockingCollection.Add(System.IO.SearchResult)System.Collections.Concurrent.BlockingCollection.Add(System.IO.SearchResult, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(System.IObservable, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(System.Net.HttpListenerContext)System.Collections.Concurrent.BlockingCollection.Add(System.Net.Sockets.SocketAsyncEventArgs)System.Collections.Concurrent.BlockingCollection.Add(System.Numerics.BigInteger, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(System.ServiceModel.Channels.IInputChannel)System.Collections.Concurrent.BlockingCollection.Add(System.Threading.Tasks.Task)System.Collections.Concurrent.BlockingCollection.Add(System.Threading.Tasks.Task, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(System.Tuple)System.Collections.Concurrent.BlockingCollection.Add(System.Tuple, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(System.Windows.Forms.TreeNode)System.Collections.Concurrent.BlockingCollection.Add(T)System.Collections.Concurrent.BlockingCollection.Add(T, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(T2)System.Collections.Concurrent.BlockingCollection.Add(Task)System.Collections.Concurrent.BlockingCollection.Add(Task, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(TaskRunner, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(TelegramOutboundMessage)System.Collections.Concurrent.BlockingCollection.Add(TElement[])System.Collections.Concurrent.BlockingCollection.Add(Telemetry.IDataEvent, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(TFinal[])System.Collections.Concurrent.BlockingCollection.Add(TIn)System.Collections.Concurrent.BlockingCollection.Add(TIn1)System.Collections.Concurrent.BlockingCollection.Add(TIn2)System.Collections.Concurrent.BlockingCollection.Add(TInner[])System.Collections.Concurrent.BlockingCollection.Add(TMessage)System.Collections.Concurrent.BlockingCollection.Add(TMessage, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.Add(TNextOutput)System.Collections.Concurrent.BlockingCollection.Add(ToastNotificationBase)System.Collections.Concurrent.BlockingCollection.Add(TOuter[])System.Collections.Concurrent.BlockingCollection.Add(TOutput)System.Collections.Concurrent.BlockingCollection.Add(TPooled)System.Collections.Concurrent.BlockingCollection.Add(TransactionEntry.Entity[])System.Collections.Concurrent.BlockingCollection.Add(TransportMessage)System.Collections.Concurrent.BlockingCollection.Add(TResult[])System.Collections.Concurrent.BlockingCollection.Add(TSource)System.Collections.Concurrent.BlockingCollection.Add(TSource[])System.Collections.Concurrent.BlockingCollection.Add(TumblrPost)System.Collections.Concurrent.BlockingCollection.Add(TWrite)System.Collections.Concurrent.BlockingCollection.Add(Umbraco.Core.Services.NotificationService.NotificationRequest)System.Collections.Concurrent.BlockingCollection.Add(UploadInfo)System.Collections.Concurrent.BlockingCollection.Add(ValidationJobState)System.Collections.Concurrent.BlockingCollection.Add(VoiceReadyEventArgs)System.Collections.Concurrent.BlockingCollection.Add(VoiceSessionDescriptionEventArgs)System.Collections.Concurrent.BlockingCollection.Add(VsKeyInfo)System.Collections.Concurrent.BlockingCollection.Add(Winter.TimeoutRequest)System.Collections.Concurrent.BlockingCollection.Add(WinUPnPFun.Form1.Target)System.Collections.Concurrent.BlockingCollection.Add(WowPacketParser.Misc.ParallelWorkProcessor.WorkItem)System.Collections.Concurrent.BlockingCollection.Add(Wrapper)System.Collections.Concurrent.BlockingCollection.Add(ZkEvent)System.Collections.Concurrent.BlockingCollection.AddToAny(System.Collections.Concurrent.BlockingCollection[], T, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.AddToAny(System.Collections.Concurrent.BlockingCollection[], TOutput)System.Collections.Concurrent.BlockingCollection.AddToAny(System.Collections.Concurrent.BlockingCollection[], TSource[])System.Collections.Concurrent.BlockingCollection.CancelWaitingConsumers()System.Collections.Concurrent.BlockingCollection.CancelWaitingProducers()System.Collections.Concurrent.BlockingCollection.CheckArray(System.Collections.Concurrent.BlockingCollection[])System.Collections.Concurrent.BlockingCollection.CheckDisposed()System.Collections.Concurrent.BlockingCollection.CompleteAdding()System.Collections.Concurrent.BlockingCollection.ComputeTimeout(int, long)System.Collections.Concurrent.BlockingCollection.CopyTo(T[], int)System.Collections.Concurrent.BlockingCollection.Dispose()System.Collections.Concurrent.BlockingCollection.Dispose(bool)System.Collections.Concurrent.BlockingCollection.GetConsumingEnumerable()System.Collections.Concurrent.BlockingCollection.GetConsumingEnumerable(System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.GetHandles(System.Collections.Concurrent.BlockingCollection[], System.Threading.CancellationToken, bool, out System.Threading.CancellationToken[])System.Collections.Concurrent.BlockingCollection.IsThereANullElement(System.Collections.Concurrent.BlockingCollection[])System.Collections.Concurrent.BlockingCollection.Poll(System.TimeSpan)System.Collections.Concurrent.BlockingCollection.Take()System.Collections.Concurrent.BlockingCollection.Take(System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TakeAsync()System.Collections.Concurrent.BlockingCollection.TakeFromAny(System.Collections.Concurrent.BlockingCollection[], out T, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.ThrowCompleteException()System.Collections.Concurrent.BlockingCollection.ToArray()System.Collections.Concurrent.BlockingCollection.TryAdd(A)System.Collections.Concurrent.BlockingCollection.TryAdd(Amazon.CloudWatchLogs.Model.InputLogEvent)System.Collections.Concurrent.BlockingCollection.TryAdd(BaseData, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryAdd(byte[], int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryAdd(CollectedMetric)System.Collections.Concurrent.BlockingCollection.TryAdd(CollectedMetric, int)System.Collections.Concurrent.BlockingCollection.TryAdd(CronusMessage)System.Collections.Concurrent.BlockingCollection.TryAdd(EventDataType)System.Collections.Concurrent.BlockingCollection.TryAdd(IHystrixInvokableInfo)System.Collections.Concurrent.BlockingCollection.TryAdd(IMemcacheRequest, int)System.Collections.Concurrent.BlockingCollection.TryAdd(IncomingMessage)System.Collections.Concurrent.BlockingCollection.TryAdd(InProcMessagePackStreamLoggerEntry)System.Collections.Concurrent.BlockingCollection.TryAdd(IPooledConnection)System.Collections.Concurrent.BlockingCollection.TryAdd(ISocketWritable)System.Collections.Concurrent.BlockingCollection.TryAdd(KeyedMessage)System.Collections.Concurrent.BlockingCollection.TryAdd(KeyedMessage, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryAdd(LibGit2Repo, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryAdd(m.Http.Metrics.RequestLogs.IndexedLog)System.Collections.Concurrent.BlockingCollection.TryAdd(MessageFrame)System.Collections.Concurrent.BlockingCollection.TryAdd(NLog.Common.AsyncLogEventInfo, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryAdd(object, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryAdd(PowerShellPoolMember, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryAdd(ProjectFilesClone)System.Collections.Concurrent.BlockingCollection.TryAdd(RabbitMQ.Client.IModel)System.Collections.Concurrent.BlockingCollection.TryAdd(RequestEnvelope)System.Collections.Concurrent.BlockingCollection.TryAdd(Revenj.Http.HttpSocketServer.RequestInfo)System.Collections.Concurrent.BlockingCollection.TryAdd(Serilog.Events.LogEvent)System.Collections.Concurrent.BlockingCollection.TryAdd(ServerMessage)System.Collections.Concurrent.BlockingCollection.TryAdd(string)System.Collections.Concurrent.BlockingCollection.TryAdd(System.Collections.Generic.List)System.Collections.Concurrent.BlockingCollection.TryAdd(System.Threading.Tasks.Task)System.Collections.Concurrent.BlockingCollection.TryAdd(System.Tuple)System.Collections.Concurrent.BlockingCollection.TryAdd(System.Tuple, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryAdd(System.WeakReference)System.Collections.Concurrent.BlockingCollection.TryAdd(System.WeakReference, int)System.Collections.Concurrent.BlockingCollection.TryAdd(T)System.Collections.Concurrent.BlockingCollection.TryAdd(T, int)System.Collections.Concurrent.BlockingCollection.TryAdd(T, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryAdd(T, System.TimeSpan)System.Collections.Concurrent.BlockingCollection.TryAdd(TcpStreamStack.ResumePacket)System.Collections.Concurrent.BlockingCollection.TryAddToAny(System.Collections.Concurrent.BlockingCollection[], int)System.Collections.Concurrent.BlockingCollection.TryAddToAny(System.Collections.Concurrent.BlockingCollection[], T, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryAddToAnyCore(System.Collections.Concurrent.BlockingCollection[], T, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryAddToAnyFast(System.Collections.Concurrent.BlockingCollection[], T)System.Collections.Concurrent.BlockingCollection.TryAddWithNoTimeValidation(T, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTake(out (RequestProcessType type, string name, System.Func request), int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTake(out Akavache.Sqlite3.OperationQueueItem)System.Collections.Concurrent.BlockingCollection.TryTake(out Amazon.CloudWatchLogs.Model.InputLogEvent)System.Collections.Concurrent.BlockingCollection.TryTake(out BasicDeliverEventArgs, int)System.Collections.Concurrent.BlockingCollection.TryTake(out BasicDeliverEventArgs, System.TimeSpan)System.Collections.Concurrent.BlockingCollection.TryTake(out BrokeredMessage, int)System.Collections.Concurrent.BlockingCollection.TryTake(out ByteBuf, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTake(out byte[])System.Collections.Concurrent.BlockingCollection.TryTake(out byte[], int)System.Collections.Concurrent.BlockingCollection.TryTake(out byte[], int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTake(out CciModuleSource, System.TimeSpan)System.Collections.Concurrent.BlockingCollection.TryTake(out ChunkContext)System.Collections.Concurrent.BlockingCollection.TryTake(out ClearScript.Manager.IRuntimeManager)System.Collections.Concurrent.BlockingCollection.TryTake(out CollectedMetric, int)System.Collections.Concurrent.BlockingCollection.TryTake(out CompletionStatus, int)System.Collections.Concurrent.BlockingCollection.TryTake(out CronusMessage, int)System.Collections.Concurrent.BlockingCollection.TryTake(out DataSlice, int)System.Collections.Concurrent.BlockingCollection.TryTake(out DeBruijnNode, int)System.Collections.Concurrent.BlockingCollection.TryTake(out EDDiscovery.StarGrid)System.Collections.Concurrent.BlockingCollection.TryTake(out EQueue.Clients.Consumers.ConsumingMessage)System.Collections.Concurrent.BlockingCollection.TryTake(out EventData, int)System.Collections.Concurrent.BlockingCollection.TryTake(out EventDataType)System.Collections.Concurrent.BlockingCollection.TryTake(out FastFetch.Git.GitIndexGenerator.LsTreeEntry, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTake(out FetchedDataChunk)System.Collections.Concurrent.BlockingCollection.TryTake(out FetchedDataChunk, int)System.Collections.Concurrent.BlockingCollection.TryTake(out FetchedDataChunk, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTake(out FetchedDataChunk, System.TimeSpan)System.Collections.Concurrent.BlockingCollection.TryTake(out HttpResponse, int)System.Collections.Concurrent.BlockingCollection.TryTake(out IMemcacheRequest, int)System.Collections.Concurrent.BlockingCollection.TryTake(out IMemcacheTransport)System.Collections.Concurrent.BlockingCollection.TryTake(out IMemcacheTransport, int)System.Collections.Concurrent.BlockingCollection.TryTake(out IMemcacheTransport, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTake(out IMessage, System.TimeSpan)System.Collections.Concurrent.BlockingCollection.TryTake(out IndexPackRequest, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTake(out InfluxData.Net.InfluxDb.Models.Point)System.Collections.Concurrent.BlockingCollection.TryTake(out int)System.Collections.Concurrent.BlockingCollection.TryTake(out int, int)System.Collections.Concurrent.BlockingCollection.TryTake(out IPooledConnection)System.Collections.Concurrent.BlockingCollection.TryTake(out IPooledConnection, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTake(out IRenderEngine)System.Collections.Concurrent.BlockingCollection.TryTake(out IRenderEngine, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTake(out ISequence, int)System.Collections.Concurrent.BlockingCollection.TryTake(out ISocketWritable)System.Collections.Concurrent.BlockingCollection.TryTake(out ITransferController, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTake(out JournalEntry, int)System.Collections.Concurrent.BlockingCollection.TryTake(out KeyedMessage, int)System.Collections.Concurrent.BlockingCollection.TryTake(out LibGit2Repo, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTake(out LogMessageEntry, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTake(out long, int)System.Collections.Concurrent.BlockingCollection.TryTake(out m.Http.Metrics.RequestLogs.IndexedLog)System.Collections.Concurrent.BlockingCollection.TryTake(out Message, System.TimeSpan)System.Collections.Concurrent.BlockingCollection.TryTake(out MessageFrame)System.Collections.Concurrent.BlockingCollection.TryTake(out Microsoft.NodejsTools.NpmUI.NpmWorker.QueuedNpmCommandInfo, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTake(out MumbleSharp.Audio.AudioEncodingBuffer.TargettedSpeech, System.TimeSpan)System.Collections.Concurrent.BlockingCollection.TryTake(out NDomain.Bus.Transport.LocalMessage, System.TimeSpan)System.Collections.Concurrent.BlockingCollection.TryTake(out Notification, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTake(out NpgsqlConnection)System.Collections.Concurrent.BlockingCollection.TryTake(out object, int)System.Collections.Concurrent.BlockingCollection.TryTake(out object, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTake(out OpenSim.Framework.Monitoring.JobEngine.Job)System.Collections.Concurrent.BlockingCollection.TryTake(out OpenSim.Framework.Monitoring.JobEngine.Job, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTake(out Orleans.Membership.ServiceFabric.FabricMembershipOracle.StatusChangeNotification, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTake(out Orleans.Runtime.Scheduler.IWorkItem, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTake(out OutgoingVoice, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTake(out Packet)System.Collections.Concurrent.BlockingCollection.TryTake(out Pair)System.Collections.Concurrent.BlockingCollection.TryTake(out PendingPacket, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTake(out PersistentTable)System.Collections.Concurrent.BlockingCollection.TryTake(out PowerShellPoolMember, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTake(out QueuedCommand, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTake(out RabbitMQ.Client.IBasicConsumer, int)System.Collections.Concurrent.BlockingCollection.TryTake(out RecordedEvent)System.Collections.Concurrent.BlockingCollection.TryTake(out RemoteCall, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTake(out ResponderWorkerWithState, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTake(out Revenj.Processing.Scope)System.Collections.Concurrent.BlockingCollection.TryTake(out SaeaAwaitable)System.Collections.Concurrent.BlockingCollection.TryTake(out SassyStudio.Compiler.BackgroundParsingTask.BackgroundParseRequest, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTake(out ServerMessage, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTake(out SimpleTask, System.TimeSpan)System.Collections.Concurrent.BlockingCollection.TryTake(out SimpleTester.EventStorageSpeedTest.ValueEvent, int)System.Collections.Concurrent.BlockingCollection.TryTake(out Span)System.Collections.Concurrent.BlockingCollection.TryTake(out Spring.Messaging.Amqp.Rabbit.Listener.Delivery, int)System.Collections.Concurrent.BlockingCollection.TryTake(out string, int)System.Collections.Concurrent.BlockingCollection.TryTake(out string, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTake(out string, System.TimeSpan)System.Collections.Concurrent.BlockingCollection.TryTake(out System.Action)System.Collections.Concurrent.BlockingCollection.TryTake(out System.Action, System.TimeSpan)System.Collections.Concurrent.BlockingCollection.TryTake(out System.Collections.Generic.KeyValuePair)System.Collections.Concurrent.BlockingCollection.TryTake(out System.Collections.Generic.KeyValuePair, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTake(out System.Collections.Generic.List)System.Collections.Concurrent.BlockingCollection.TryTake(out System.Drawing.Bitmap, int)System.Collections.Concurrent.BlockingCollection.TryTake(out System.Drawing.Point)System.Collections.Concurrent.BlockingCollection.TryTake(out System.Net.Sockets.SocketAsyncEventArgs)System.Collections.Concurrent.BlockingCollection.TryTake(out System.Threading.Tasks.Task, int)System.Collections.Concurrent.BlockingCollection.TryTake(out System.Tuple)System.Collections.Concurrent.BlockingCollection.TryTake(out System.Tuple, int)System.Collections.Concurrent.BlockingCollection.TryTake(out System.WeakReference)System.Collections.Concurrent.BlockingCollection.TryTake(out T)System.Collections.Concurrent.BlockingCollection.TryTake(out T, int)System.Collections.Concurrent.BlockingCollection.TryTake(out T, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTake(out T, int, System.Threading.CancellationToken, bool)System.Collections.Concurrent.BlockingCollection.TryTake(out T, System.TimeSpan)System.Collections.Concurrent.BlockingCollection.TryTake(out TaskRunner, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTake(out TcpStreamStack.ResumePacket)System.Collections.Concurrent.BlockingCollection.TryTake(out Telemetry.IDataEvent, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTake(out TPooled)System.Collections.Concurrent.BlockingCollection.TryTake(out TPooled, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTake(out TransportMessage)System.Collections.Concurrent.BlockingCollection.TryTake(out Umbraco.Core.Services.NotificationService.NotificationRequest, int)System.Collections.Concurrent.BlockingCollection.TryTake(out UploadInfo, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTake(out Winter.TimeoutRequest)System.Collections.Concurrent.BlockingCollection.TryTakeFromAny(System.Collections.Concurrent.BlockingCollection[], out Orleans.Runtime.Scheduler.IWorkItem, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTakeFromAny(System.Collections.Concurrent.BlockingCollection[], out T, int)System.Collections.Concurrent.BlockingCollection.TryTakeFromAny(System.Collections.Concurrent.BlockingCollection[], out TInput, int, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTakeFromAnyCore(System.Collections.Concurrent.BlockingCollection[], out T, int, bool, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTakeFromAnyCoreSlow(System.Collections.Concurrent.BlockingCollection[], out T, int, bool, System.Threading.CancellationToken)System.Collections.Concurrent.BlockingCollection.TryTakeWithNoTimeValidation(out T, int, System.Threading.CancellationToken, System.Threading.CancellationTokenSource)System.Collections.Concurrent.BlockingCollection.UpdateTimeOut(uint, int)System.Collections.Concurrent.BlockingCollection.ValidateCollectionsArray(System.Collections.Concurrent.BlockingCollection[], bool)System.Collections.Concurrent.BlockingCollection.ValidateMillisecondsTimeout(int)System.Collections.Concurrent.BlockingCollection.ValidateTimeout(System.TimeSpan)System.Collections.Concurrent.CDSCollectionETWBCLProvider.ConcurrentBag_TryPeekSteals()System.Collections.Concurrent.CDSCollectionETWBCLProvider.ConcurrentBag_TryTakeSteals()System.Collections.Concurrent.CDSCollectionETWBCLProvider.ConcurrentDictionary_AcquiringAllLocks(int)System.Collections.Concurrent.CDSCollectionETWBCLProvider.ConcurrentStack_FastPopFailed(int)System.Collections.Concurrent.CDSCollectionETWBCLProvider.ConcurrentStack_FastPushFailed(int)System.Collections.Concurrent.ConcurrentBag.AcquireAllLocks()System.Collections.Concurrent.ConcurrentBag.Add((CodeAction, Document))System.Collections.Concurrent.ConcurrentBag.Add((Microsoft.CodeAnalysis.Diagnostic diagnostic, CodeAction action))System.Collections.Concurrent.ConcurrentBag.Add(Abot.Tests.Integration.PageResult)System.Collections.Concurrent.ConcurrentBag.Add(Abp.Auditing.AuditInfo)System.Collections.Concurrent.ConcurrentBag.Add(Adxstudio.Xrm.Web.UI.ViewDataAdapter.FetchResult)System.Collections.Concurrent.ConcurrentBag.Add(Amib.Threading.SmartThreadPool)System.Collections.Concurrent.ConcurrentBag.Add(AMQPQueue)System.Collections.Concurrent.ConcurrentBag.Add(AMQPQueueMetric)System.Collections.Concurrent.ConcurrentBag.Add(Animate)System.Collections.Concurrent.ConcurrentBag.Add(AppendEntriesResponse)System.Collections.Concurrent.ConcurrentBag.Add(ArenaTeamMember)System.Collections.Concurrent.ConcurrentBag.Add(Assembly)System.Collections.Concurrent.ConcurrentBag.Add(AstNode)System.Collections.Concurrent.ConcurrentBag.Add(BaseItem)System.Collections.Concurrent.ConcurrentBag.Add(BCard)System.Collections.Concurrent.ConcurrentBag.Add(bool)System.Collections.Concurrent.ConcurrentBag.Add(BosunReporter.Metrics.EventGauge.PendingMetric)System.Collections.Concurrent.ConcurrentBag.Add(BoxEnterpriseEvent)System.Collections.Concurrent.ConcurrentBag.Add(Buff)System.Collections.Concurrent.ConcurrentBag.Add(BusyToken)System.Collections.Concurrent.ConcurrentBag.Add(byte)System.Collections.Concurrent.ConcurrentBag.Add(byte[])System.Collections.Concurrent.ConcurrentBag.Add(CacheKey)System.Collections.Concurrent.ConcurrentBag.Add(CalculatedProject)System.Collections.Concurrent.ConcurrentBag.Add(CancellableTask)System.Collections.Concurrent.ConcurrentBag.Add(Chapter6.Recipe4.Program.CrawlingTask)System.Collections.Concurrent.ConcurrentBag.Add(char[])System.Collections.Concurrent.ConcurrentBag.Add(ChildProgressBar)System.Collections.Concurrent.ConcurrentBag.Add(Chummer.LanguageManager.LanguageString)System.Collections.Concurrent.ConcurrentBag.Add(ChummerDataViewer.Model.DownloaderWorker.DownloadTask)System.Collections.Concurrent.ConcurrentBag.Add(Class)System.Collections.Concurrent.ConcurrentBag.Add(ClientSession)System.Collections.Concurrent.ConcurrentBag.Add(CloudStorageAccount)System.Collections.Concurrent.ConcurrentBag.Add(Component)System.Collections.Concurrent.ConcurrentBag.Add(Connection)System.Collections.Concurrent.ConcurrentBag.Add(CriAdxKey)System.Collections.Concurrent.ConcurrentBag.Add(DataLoaderContext)System.Collections.Concurrent.ConcurrentBag.Add(DataObject)System.Collections.Concurrent.ConcurrentBag.Add(DataSourceWrapperInfo)System.Collections.Concurrent.ConcurrentBag.Add(DeBruijnPath)System.Collections.Concurrent.ConcurrentBag.Add(Declaration)System.Collections.Concurrent.ConcurrentBag.Add(Deflector.IMethodCallMap)System.Collections.Concurrent.ConcurrentBag.Add(DetectedProc)System.Collections.Concurrent.ConcurrentBag.Add(dgItem)System.Collections.Concurrent.ConcurrentBag.Add(DiagnosticRecord)System.Collections.Concurrent.ConcurrentBag.Add(DocumentRecord)System.Collections.Concurrent.ConcurrentBag.Add(double)System.Collections.Concurrent.ConcurrentBag.Add(dynamic)System.Collections.Concurrent.ConcurrentBag.Add(Event)System.Collections.Concurrent.ConcurrentBag.Add(EventContainer)System.Collections.Concurrent.ConcurrentBag.Add(EventEntry)System.Collections.Concurrent.ConcurrentBag.Add(EventHubQueueCacheForTesting)System.Collections.Concurrent.ConcurrentBag.Add(EventRecord)System.Collections.Concurrent.ConcurrentBag.Add(ExecutionChangeToken)System.Collections.Concurrent.ConcurrentBag.Add(ExplosionParticle)System.Collections.Concurrent.ConcurrentBag.Add(ExtendedLoggingEvent)System.Collections.Concurrent.ConcurrentBag.Add(FailureCountingUri)System.Collections.Concurrent.ConcurrentBag.Add(FetcherRunnable)System.Collections.Concurrent.ConcurrentBag.Add(FileListDataItem)System.Collections.Concurrent.ConcurrentBag.Add(float)System.Collections.Concurrent.ConcurrentBag.Add(GLDescriptorSet)System.Collections.Concurrent.ConcurrentBag.Add(GraphQL.Instrumentation.PerfRecord)System.Collections.Concurrent.ConcurrentBag.Add(GreenPipes.BenchmarkConsole.Throughput.MessageMetricCapture.ConsumedMessage)System.Collections.Concurrent.ConcurrentBag.Add(GreenPipes.BenchmarkConsole.Throughput.MessageMetricCapture.SentMessage)System.Collections.Concurrent.ConcurrentBag.Add(Grove.AI.DeckEvaluator.NumberedDeck)System.Collections.Concurrent.ConcurrentBag.Add(Helios.FsCheck.Tests.Concurrency.ObjectPoolSpec.MyPooledObject)System.Collections.Concurrent.ConcurrentBag.Add(Host)System.Collections.Concurrent.ConcurrentBag.Add(Http2.ConnectionWriter.WriteRequest)System.Collections.Concurrent.ConcurrentBag.Add(IBigtableFieldSerializer)System.Collections.Concurrent.ConcurrentBag.Add(IBusComponent)System.Collections.Concurrent.ConcurrentBag.Add(IChainStateCursor)System.Collections.Concurrent.ConcurrentBag.Add(IChannel)System.Collections.Concurrent.ConcurrentBag.Add(IComponentRegistration)System.Collections.Concurrent.ConcurrentBag.Add(IConnection)System.Collections.Concurrent.ConcurrentBag.Add(IConnectionHeartbeatListener)System.Collections.Concurrent.ConcurrentBag.Add(IConnectionListener)System.Collections.Concurrent.ConcurrentBag.Add(IdentifierReference)System.Collections.Concurrent.ConcurrentBag.Add(IDocument)System.Collections.Concurrent.ConcurrentBag.Add(IDomainEvent)System.Collections.Concurrent.ConcurrentBag.Add(IEntity)System.Collections.Concurrent.ConcurrentBag.Add(IEvent)System.Collections.Concurrent.ConcurrentBag.Add(IExecutionPipelineContext)System.Collections.Concurrent.ConcurrentBag.Add(IFunctionInfo)System.Collections.Concurrent.ConcurrentBag.Add(IGenerator)System.Collections.Concurrent.ConcurrentBag.Add(IInspectionResult)System.Collections.Concurrent.ConcurrentBag.Add(ImageItem)System.Collections.Concurrent.ConcurrentBag.Add(IMessageConsumer)System.Collections.Concurrent.ConcurrentBag.Add(IMessageEventSubscriber)System.Collections.Concurrent.ConcurrentBag.Add(IMessageSubscription)System.Collections.Concurrent.ConcurrentBag.Add(IModel)System.Collections.Concurrent.ConcurrentBag.Add(int)System.Collections.Concurrent.ConcurrentBag.Add(IPoolableObject)System.Collections.Concurrent.ConcurrentBag.Add(IPortalBusProvider)System.Collections.Concurrent.ConcurrentBag.Add(IReference)System.Collections.Concurrent.ConcurrentBag.Add(IReloadClient)System.Collections.Concurrent.ConcurrentBag.Add(IRescalingReservoir)System.Collections.Concurrent.ConcurrentBag.Add(IRuleResult)System.Collections.Concurrent.ConcurrentBag.Add(ISubscriber)System.Collections.Concurrent.ConcurrentBag.Add(ISubscription)System.Collections.Concurrent.ConcurrentBag.Add(ITelemetryConsumer)System.Collections.Concurrent.ConcurrentBag.Add(Item)System.Collections.Concurrent.ConcurrentBag.Add(ITickingMeter)System.Collections.Concurrent.ConcurrentBag.Add(IZooKeeperStateListener)System.Collections.Concurrent.ConcurrentBag.Add(JSIL.AssemblyTranslator.MethodToAnalyze)System.Collections.Concurrent.ConcurrentBag.Add(JSIL.Tests.Evaluator)System.Collections.Concurrent.ConcurrentBag.Add(JsonNode)System.Collections.Concurrent.ConcurrentBag.Add(kino.Tests.Helpers.ActorHostSocketFactory.SocketMeta)System.Collections.Concurrent.ConcurrentBag.Add(kino.Tests.Helpers.ClusterMonitorSocketFactory.SocketMeta)System.Collections.Concurrent.ConcurrentBag.Add(Lease)System.Collections.Concurrent.ConcurrentBag.Add(libyaraNET.ScanResult)System.Collections.Concurrent.ConcurrentBag.Add(LoadedDefinitionInfo)System.Collections.Concurrent.ConcurrentBag.Add(LocalizedString)System.Collections.Concurrent.ConcurrentBag.Add(LogChatDTO)System.Collections.Concurrent.ConcurrentBag.Add(LogCommandsDTO)System.Collections.Concurrent.ConcurrentBag.Add(LogFileContext)System.Collections.Concurrent.ConcurrentBag.Add(long)System.Collections.Concurrent.ConcurrentBag.Add(Magnesium.Metal.AmtDescriptorSet)System.Collections.Concurrent.ConcurrentBag.Add(MapCell)System.Collections.Concurrent.ConcurrentBag.Add(Match)System.Collections.Concurrent.ConcurrentBag.Add(MediaBrowser.Model.Updates.InstallationInfo)System.Collections.Concurrent.ConcurrentBag.Add(Meme)System.Collections.Concurrent.ConcurrentBag.Add(Mesh)System.Collections.Concurrent.ConcurrentBag.Add(Microsoft.ApplicationInsights.Channel.ITelemetry)System.Collections.Concurrent.ConcurrentBag.Add(Microsoft.Azure.KeyVault.Core.IKeyResolver)System.Collections.Concurrent.ConcurrentBag.Add(Microsoft.CodeAnalysis.CSharp.Symbol)System.Collections.Concurrent.ConcurrentBag.Add(Microsoft.CodeAnalysis.Diagnostic)System.Collections.Concurrent.ConcurrentBag.Add(Microsoft.CodeAnalysis.ISymbol)System.Collections.Concurrent.ConcurrentBag.Add(Microsoft.CodeAnalysis.SyntaxTree)System.Collections.Concurrent.ConcurrentBag.Add(Microsoft.DotNet.Tests.FakeRecordEventNameTelemetry.LogEntry)System.Collections.Concurrent.ConcurrentBag.Add(Microsoft.Research.Naiad.Frameworks.DifferentialDataflow.NaiadDataStreamProtocol)System.Collections.Concurrent.ConcurrentBag.Add(Microsoft.Research.Naiad.Serialization.RecvBufferPage)System.Collections.Concurrent.ConcurrentBag.Add(Microsoft.VisualStudio.Shell.Interop.IVsHierarchy)System.Collections.Concurrent.ConcurrentBag.Add(Microsoft.VisualStudio.TestPlatform.ObjectModel.TestCase)System.Collections.Concurrent.ConcurrentBag.Add(Microsoft.WindowsAzure.Build.Tasks.SdkProjectMetaData)System.Collections.Concurrent.ConcurrentBag.Add(Microsoft.Xrm.Sdk.Entity)System.Collections.Concurrent.ConcurrentBag.Add(MineCase.Buffers.BufferPool.BufferPoolScope)System.Collections.Concurrent.ConcurrentBag.Add(MockSocket)System.Collections.Concurrent.ConcurrentBag.Add(ModuleInfo)System.Collections.Concurrent.ConcurrentBag.Add(MongoDB.Bson.BsonDocument)System.Collections.Concurrent.ConcurrentBag.Add(MonsterToSummon)System.Collections.Concurrent.ConcurrentBag.Add(MultiShardException)System.Collections.Concurrent.ConcurrentBag.Add(NATS.Client.SingleUseChannel)System.Collections.Concurrent.ConcurrentBag.Add(NavigateToItem)System.Collections.Concurrent.ConcurrentBag.Add(NHibernate.Engine.ISessionImplementor)System.Collections.Concurrent.ConcurrentBag.Add(NimbusMessage)System.Collections.Concurrent.ConcurrentBag.Add(Nowin.ConnectionBlock)System.Collections.Concurrent.ConcurrentBag.Add(NpcMonsterSkill)System.Collections.Concurrent.ConcurrentBag.Add(NSQnet.NSQSubscriber.Subscription)System.Collections.Concurrent.ConcurrentBag.Add(NuGet.IPackageRepository)System.Collections.Concurrent.ConcurrentBag.Add(object)System.Collections.Concurrent.ConcurrentBag.Add(Ocelot.IntegrationTests.ThreadSafeHeadersTests.ThreadSafeHeadersTestResult)System.Collections.Concurrent.ConcurrentBag.Add(Orchard.Environment.ShellBuilders.ShellContainerFactory.NamedRegistration)System.Collections.Concurrent.ConcurrentBag.Add(Orleans.Providers.ProviderTypeLoader)System.Collections.Concurrent.ConcurrentBag.Add(Partition)System.Collections.Concurrent.ConcurrentBag.Add(PerfTraceEvent)System.Collections.Concurrent.ConcurrentBag.Add(PerfTraceThreadContext)System.Collections.Concurrent.ConcurrentBag.Add(PersistentTable)System.Collections.Concurrent.ConcurrentBag.Add(PKM)System.Collections.Concurrent.ConcurrentBag.Add(PlaceholderListDatabase.PlaceholderData)System.Collections.Concurrent.ConcurrentBag.Add(POESKillTree.TreeGenerator.Algorithm.LinkedListPriorityQueue.DataArrays)System.Collections.Concurrent.ConcurrentBag.Add(PollResponse)System.Collections.Concurrent.ConcurrentBag.Add(PortListener)System.Collections.Concurrent.ConcurrentBag.Add(QualifiedModuleName)System.Collections.Concurrent.ConcurrentBag.Add(RabbitChannel)System.Collections.Concurrent.ConcurrentBag.Add(RabbitMQ.Client.IModel)System.Collections.Concurrent.ConcurrentBag.Add(RCONMessageAnswer)System.Collections.Concurrent.ConcurrentBag.Add(ReplayMetadata)System.Collections.Concurrent.ConcurrentBag.Add(RepositoryModel)System.Collections.Concurrent.ConcurrentBag.Add(Response)System.Collections.Concurrent.ConcurrentBag.Add(RiakClient.Models.RiakObjectId)System.Collections.Concurrent.ConcurrentBag.Add(Rosalia.Core.Tasks.IdentityWithResult)System.Collections.Concurrent.ConcurrentBag.Add(Serilog.Events.LogEvent)System.Collections.Concurrent.ConcurrentBag.Add(ServerPackage)System.Collections.Concurrent.ConcurrentBag.Add(ServiceBus.Tests.TestStreamProviders.EHStreamProviderWithCreatedCacheList.AdapterFactory.QueueCacheForTesting)System.Collections.Concurrent.ConcurrentBag.Add(ServiceConnect.Client)System.Collections.Concurrent.ConcurrentBag.Add(SharpDBConnection)System.Collections.Concurrent.ConcurrentBag.Add(SharpDX.Direct3D12.GraphicsCommandList)System.Collections.Concurrent.ConcurrentBag.Add(Sharpmake.Generators.VisualStudio.CSproj.CsProjSubTypesInfos)System.Collections.Concurrent.ConcurrentBag.Add(SimulatedUserAccount)System.Collections.Concurrent.ConcurrentBag.Add(SmartStore.Web.Framework.SmartUrlRoutingModule.RoutablePath)System.Collections.Concurrent.ConcurrentBag.Add(SocketAwaitable)System.Collections.Concurrent.ConcurrentBag.Add(SonarAnalyzer.Common.SyntaxNodeWithSymbol)System.Collections.Concurrent.ConcurrentBag.Add(StackExchange.Opserver.Data.IIssuesProvider)System.Collections.Concurrent.ConcurrentBag.Add(StackExchange.Opserver.Data.INodeRoleProvider)System.Collections.Concurrent.ConcurrentBag.Add(StaticBuffDTO)System.Collections.Concurrent.ConcurrentBag.Add(Stratis.Bitcoin.Features.Wallet)System.Collections.Concurrent.ConcurrentBag.Add(StressTestMessage)System.Collections.Concurrent.ConcurrentBag.Add(StressTestResponseMessage)System.Collections.Concurrent.ConcurrentBag.Add(string)System.Collections.Concurrent.ConcurrentBag.Add(StructureMap.Container)System.Collections.Concurrent.ConcurrentBag.Add(SubscriptionBuffer)System.Collections.Concurrent.ConcurrentBag.Add(SubscriptionDataConfig)System.Collections.Concurrent.ConcurrentBag.Add(SubscriptionEntity)System.Collections.Concurrent.ConcurrentBag.Add(SuppressedRecord)System.Collections.Concurrent.ConcurrentBag.Add(System.Action)System.Collections.Concurrent.ConcurrentBag.Add(System.Collections.Concurrent.ConcurrentDictionary)System.Collections.Concurrent.ConcurrentBag.Add(System.Collections.Concurrent.ConcurrentStack)System.Collections.Concurrent.ConcurrentBag.Add(System.Collections.Generic.IDictionary)System.Collections.Concurrent.ConcurrentBag.Add(System.Collections.Generic.IEnumerable)System.Collections.Concurrent.ConcurrentBag.Add(System.Collections.Generic.List)System.Collections.Concurrent.ConcurrentBag.Add(System.Collections.Generic.Stack)System.Collections.Concurrent.ConcurrentBag.Add(System.Diagnostics.Process)System.Collections.Concurrent.ConcurrentBag.Add(System.Exception)System.Collections.Concurrent.ConcurrentBag.Add(System.Func)System.Collections.Concurrent.ConcurrentBag.Add(System.Guid)System.Collections.Concurrent.ConcurrentBag.Add(System.IDisposable)System.Collections.Concurrent.ConcurrentBag.Add(System.IObserver)System.Collections.Concurrent.ConcurrentBag.Add(System.Linq.IGrouping)System.Collections.Concurrent.ConcurrentBag.Add(System.Management.Automation.ErrorRecord)System.Collections.Concurrent.ConcurrentBag.Add(System.Net.HttpStatusCode)System.Collections.Concurrent.ConcurrentBag.Add(System.Net.IPAddress)System.Collections.Concurrent.ConcurrentBag.Add(System.Runtime.ExceptionServices.ExceptionDispatchInfo)System.Collections.Concurrent.ConcurrentBag.Add(System.Signature)System.Collections.Concurrent.ConcurrentBag.Add(System.Threading.CancellationTokenRegistration)System.Collections.Concurrent.ConcurrentBag.Add(System.Threading.CountdownEvent)System.Collections.Concurrent.ConcurrentBag.Add(System.Threading.Tasks.Task)System.Collections.Concurrent.ConcurrentBag.Add(System.Threading.Tasks.TaskCompletionSource)System.Collections.Concurrent.ConcurrentBag.Add(System.Threading.Thread)System.Collections.Concurrent.ConcurrentBag.Add(System.Tuple)System.Collections.Concurrent.ConcurrentBag.Add(System.Type)System.Collections.Concurrent.ConcurrentBag.Add(System.WeakReference)System.Collections.Concurrent.ConcurrentBag.Add(T)System.Collections.Concurrent.ConcurrentBag.Add(T2)System.Collections.Concurrent.ConcurrentBag.Add(TableResult)System.Collections.Concurrent.ConcurrentBag.Add(TelemetryEvent)System.Collections.Concurrent.ConcurrentBag.Add(TEntity)System.Collections.Concurrent.ConcurrentBag.Add(TestActor)System.Collections.Concurrent.ConcurrentBag.Add(TestBroker)System.Collections.Concurrent.ConcurrentBag.Add(TodoItem)System.Collections.Concurrent.ConcurrentBag.Add(Transaction)System.Collections.Concurrent.ConcurrentBag.Add(TResource)System.Collections.Concurrent.ConcurrentBag.Add(TSource)System.Collections.Concurrent.ConcurrentBag.Add(TumblrPost)System.Collections.Concurrent.ConcurrentBag.Add(TUser)System.Collections.Concurrent.ConcurrentBag.Add(TValue)System.Collections.Concurrent.ConcurrentBag.Add(T[])System.Collections.Concurrent.ConcurrentBag.Add(UiArchiveNode)System.Collections.Concurrent.ConcurrentBag.Add(UiNode)System.Collections.Concurrent.ConcurrentBag.Add(UnboundMemberDeclaration)System.Collections.Concurrent.ConcurrentBag.Add(UserType)System.Collections.Concurrent.ConcurrentBag.Add(ushort)System.Collections.Concurrent.ConcurrentBag.Add(Utilities.DataTypes.TagDictionary.TaggedItem)System.Collections.Concurrent.ConcurrentBag.Add(ValidationError)System.Collections.Concurrent.ConcurrentBag.Add(VillageObject)System.Collections.Concurrent.ConcurrentBag.Add(VMCS)System.Collections.Concurrent.ConcurrentBag.Add(WebApplications.Utilities.Logging.Log)System.Collections.Concurrent.ConcurrentBag.AddHint(int)System.Collections.Concurrent.ConcurrentBag.AddIf(System.Predicate, params T[])System.Collections.Concurrent.ConcurrentBag.AddIf(System.Predicate, System.Collections.Generic.IEnumerable)System.Collections.Concurrent.ConcurrentBag.AddInternal(System.Collections.Concurrent.ConcurrentBag.ThreadLocalList, T)System.Collections.Concurrent.ConcurrentBag.CanSteal(System.Collections.Concurrent.ConcurrentBag.ThreadLocalList)System.Collections.Concurrent.ConcurrentBag.Contains(T, System.Collections.Generic.IEqualityComparer)System.Collections.Concurrent.ConcurrentBag.CopyTo(SocketAwaitable[], int)System.Collections.Concurrent.ConcurrentBag.CopyTo(T[], int)System.Collections.Concurrent.ConcurrentBag.CopyTo(T[], int, int)System.Collections.Concurrent.ConcurrentBag.FreezeBag(ref bool)System.Collections.Concurrent.ConcurrentBag.GetBag(out int, bool)System.Collections.Concurrent.ConcurrentBag.GetEnumerator()System.Collections.Concurrent.ConcurrentBag.GetEnumeratorInternal()System.Collections.Concurrent.ConcurrentBag.GetIndex()System.Collections.Concurrent.ConcurrentBag.GetThreadList(bool)System.Collections.Concurrent.ConcurrentBag.GetUnownedList()System.Collections.Concurrent.ConcurrentBag.ReleaseAllLocks()System.Collections.Concurrent.ConcurrentBag.Steal(out T, bool)System.Collections.Concurrent.ConcurrentBag.ThreadLocalList.Add(T, bool)System.Collections.Concurrent.ConcurrentBag.ThreadLocalList.Peek(out T)System.Collections.Concurrent.ConcurrentBag.ThreadLocalList.Remove(out T)System.Collections.Concurrent.ConcurrentBag.ThreadLocalList.Steal(out T, bool)System.Collections.Concurrent.ConcurrentBag.TidyBag(int, CyclicDeque)System.Collections.Concurrent.ConcurrentBag.ToArray()System.Collections.Concurrent.ConcurrentBag.ToList()System.Collections.Concurrent.ConcurrentBag.TryGetHint(out int)System.Collections.Concurrent.ConcurrentBag.TryPeek(out BusyToken)System.Collections.Concurrent.ConcurrentBag.TryPeek(out NimbusMessage)System.Collections.Concurrent.ConcurrentBag.TrySteal(System.Collections.Concurrent.ConcurrentBag.ThreadLocalList, out T, bool)System.Collections.Concurrent.ConcurrentBag.TryTake(out AMQPQueue)System.Collections.Concurrent.ConcurrentBag.TryTake(out BusyToken)System.Collections.Concurrent.ConcurrentBag.TryTake(out byte[])System.Collections.Concurrent.ConcurrentBag.TryTake(out Chapter6.Recipe4.Program.CrawlingTask)System.Collections.Concurrent.ConcurrentBag.TryTake(out char[])System.Collections.Concurrent.ConcurrentBag.TryTake(out ChummerDataViewer.Model.DownloaderWorker.DownloadTask)System.Collections.Concurrent.ConcurrentBag.TryTake(out Component)System.Collections.Concurrent.ConcurrentBag.TryTake(out Connection)System.Collections.Concurrent.ConcurrentBag.TryTake(out ExecutionChangeToken)System.Collections.Concurrent.ConcurrentBag.TryTake(out ExplosionParticle)System.Collections.Concurrent.ConcurrentBag.TryTake(out ExtendedLoggingEvent)System.Collections.Concurrent.ConcurrentBag.TryTake(out GLDescriptorSet)System.Collections.Concurrent.ConcurrentBag.TryTake(out Http2.ConnectionWriter.WriteRequest)System.Collections.Concurrent.ConcurrentBag.TryTake(out IBusComponent)System.Collections.Concurrent.ConcurrentBag.TryTake(out IEntity)System.Collections.Concurrent.ConcurrentBag.TryTake(out IModel)System.Collections.Concurrent.ConcurrentBag.TryTake(out Implementation)System.Collections.Concurrent.ConcurrentBag.TryTake(out int)System.Collections.Concurrent.ConcurrentBag.TryTake(out IPoolableObject)System.Collections.Concurrent.ConcurrentBag.TryTake(out IRescalingReservoir)System.Collections.Concurrent.ConcurrentBag.TryTake(out Item)System.Collections.Concurrent.ConcurrentBag.TryTake(out ITickingMeter)System.Collections.Concurrent.ConcurrentBag.TryTake(out JSIL.AssemblyTranslator.MethodToAnalyze)System.Collections.Concurrent.ConcurrentBag.TryTake(out JSIL.Tests.Evaluator)System.Collections.Concurrent.ConcurrentBag.TryTake(out JsonNode)System.Collections.Concurrent.ConcurrentBag.TryTake(out Magnesium.Metal.AmtDescriptorSet)System.Collections.Concurrent.ConcurrentBag.TryTake(out Magnesium.OpenGL.IGLDescriptorSet)System.Collections.Concurrent.ConcurrentBag.TryTake(out Mesh)System.Collections.Concurrent.ConcurrentBag.TryTake(out Microsoft.Research.Naiad.Frameworks.DifferentialDataflow.NaiadDataStreamProtocol)System.Collections.Concurrent.ConcurrentBag.TryTake(out Microsoft.Research.Naiad.Serialization.RecvBufferPage)System.Collections.Concurrent.ConcurrentBag.TryTake(out MineCase.Buffers.BufferPool.BufferPoolScope)System.Collections.Concurrent.ConcurrentBag.TryTake(out NATS.Client.SingleUseChannel)System.Collections.Concurrent.ConcurrentBag.TryTake(out NavigateToItem)System.Collections.Concurrent.ConcurrentBag.TryTake(out NimbusMessage)System.Collections.Concurrent.ConcurrentBag.TryTake(out Nowin.ConnectionBlock)System.Collections.Concurrent.ConcurrentBag.TryTake(out PersistentTable)System.Collections.Concurrent.ConcurrentBag.TryTake(out PollResponse)System.Collections.Concurrent.ConcurrentBag.TryTake(out RabbitChannel)System.Collections.Concurrent.ConcurrentBag.TryTake(out RCONMessageAnswer)System.Collections.Concurrent.ConcurrentBag.TryTake(out RepositoryModel)System.Collections.Concurrent.ConcurrentBag.TryTake(out SharpDBConnection)System.Collections.Concurrent.ConcurrentBag.TryTake(out SharpDX.Direct3D12.GraphicsCommandList)System.Collections.Concurrent.ConcurrentBag.TryTake(out SocketAwaitable)System.Collections.Concurrent.ConcurrentBag.TryTake(out string)System.Collections.Concurrent.ConcurrentBag.TryTake(out System.Action)System.Collections.Concurrent.ConcurrentBag.TryTake(out System.Collections.Concurrent.ConcurrentStack)System.Collections.Concurrent.ConcurrentBag.TryTake(out System.Collections.Generic.List)System.Collections.Concurrent.ConcurrentBag.TryTake(out System.Collections.Generic.Stack)System.Collections.Concurrent.ConcurrentBag.TryTake(out System.Diagnostics.Process)System.Collections.Concurrent.ConcurrentBag.TryTake(out System.IDisposable)System.Collections.Concurrent.ConcurrentBag.TryTake(out System.IObserver)System.Collections.Concurrent.ConcurrentBag.TryTake(out System.Runtime.ExceptionServices.ExceptionDispatchInfo)System.Collections.Concurrent.ConcurrentBag.TryTake(out System.Threading.CancellationTokenRegistration)System.Collections.Concurrent.ConcurrentBag.TryTake(out System.Threading.Tasks.Task)System.Collections.Concurrent.ConcurrentBag.TryTake(out System.Tuple)System.Collections.Concurrent.ConcurrentBag.TryTake(out System.WeakReference)System.Collections.Concurrent.ConcurrentBag.TryTake(out T)System.Collections.Concurrent.ConcurrentBag.TryTake(out TelemetryEvent)System.Collections.Concurrent.ConcurrentBag.TryTake(out TResource)System.Collections.Concurrent.ConcurrentBag.TryTake(out TSource)System.Collections.Concurrent.ConcurrentBag.TryTake(out T[])System.Collections.Concurrent.ConcurrentBag.TryTake(out VillageObject)System.Collections.Concurrent.ConcurrentBag.TryTake(out WebApplications.Utilities.Logging.Log)System.Collections.Concurrent.ConcurrentBag.TryTakeOrPeek(out T, bool)System.Collections.Concurrent.ConcurrentBag.UnfreezeBag(bool)System.Collections.Concurrent.ConcurrentBag.WaitAllOperations()System.Collections.Concurrent.ConcurrentDictionary.AcquireAllLocks(ref int)System.Collections.Concurrent.ConcurrentDictionary.AcquireLocks(int, int, ref int)System.Collections.Concurrent.ConcurrentDictionary.Add(TKey, TValue)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(ActorId, System.Collections.Generic.HashSet, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(AutoMapper.TypePair, IEquivalentComparer, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(Bloom.web.UrlType, string, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(BruTile.TileIndex, long, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(BundleDefinition, System.Collections.Generic.IEnumerable, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(byte, int, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(byte[], bool, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(CachingKey, object, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(CombGuid, ScheduledAction, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(CommandId, ProductiveRage.SqlProxyAndReplay.DataProviderService.ProxyImplementations.ConcurrentParameterToCommandLookup.SimpleImmutableList, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(DataContextStack, int, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(Declaration, byte, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(EntityTagKey, TimedEntityTagHeaderValue, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(Exchange.KeyID, Exchange, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(FilePath, CodeGeneratorDependency, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(FilePath, FilePath, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(FilePath, System.Func, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(Google.Protobuf.ByteString, Session, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(GrainId, System.Collections.Generic.List, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(GrainId, System.Tuple, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(GroupToken, AlbumComponent, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(GuidId, Orleans.Streams.IStreamSubscriptionHandle, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(HttpClient, System.DateTime, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(HystrixCommandIdentifier, System.Func, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(ICluster, ClusterVersion, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(IdentifierType, string, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(IdentifierType, System.Func, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(IGuild, Cards, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(IGuildUser, int, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(int, Address, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(int, Foo, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(int, int, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(int, IRemotingMessage, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(int, long, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(int, MapArea, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(int, MapCell, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(int, MapInfo, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(int, object, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(int, Quest, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(int, string, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(int, System.Collections.Concurrent.ConcurrentBag, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(int, System.Func, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(int, System.Guid, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(int, System.Threading.Tasks.Task, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(int, System.Threading.Tasks.TaskCompletionSource, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(int, T, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(int, TValue, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(int, UserFlag, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(IP.SocketID, Network_Manager.Jobs.Extensions.ByteCounter.ByteTable.Bytes, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(IProjectFile, TextRange, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(ISpeculativeExecutionPlan, int, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(ITextChannel, System.Collections.Generic.List, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(IViewManager, System.Func, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(K, V, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(LiveStacks.OneStack, int, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(long, CacheEntry, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(long, IClassDefinition, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(long, ICommandResponse, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(long, InMemoryVertex, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(long, QuantConnect.Brokerages.Tradier.TradierBrokerage.ContingentOrderQueue, System.Func)System.Collections.Concurrent.ConcurrentDictionary.AddOrUpdate(long, string, System.Func)