421 references to new
Aspire.Dashboard (3)
Model\ResourceViewModel.cs (1)
151private static readonly ConcurrentDictionary<IconKey, CustomIcon?> s_iconCache = new();
Otlp\Storage\TelemetryRepository.cs (1)
34private readonly ConcurrentDictionary<ApplicationKey, OtlpApplication> _applications = new();
Utils\FormatHelpers.cs (1)
27private static readonly ConcurrentDictionary<CultureDetailsKey, MillisecondFormatStrings> s_formatStrings = new();
Aspire.Hosting (5)
ApplicationModel\ResourceLoggerService.cs (1)
22private readonly ConcurrentDictionary<string, ResourceLoggerState> _loggers = new();
ApplicationModel\ResourceNotificationService.cs (1)
20private readonly ConcurrentDictionary<(IResource, string), ResourceNotificationState> _resourceNotificationStates = new();
Dcp\ApplicationExecutor.cs (1)
112private readonly ConcurrentDictionary<string, (CancellationTokenSource Cancellation, Task Task)> _logStreams = new();
Eventing\DistributedApplicationEventing.cs (2)
12private readonly ConcurrentDictionary<Type, List<DistributedApplicationEventSubscription>> _eventSubscriptionListLookup = new(); 13private readonly ConcurrentDictionary<DistributedApplicationEventSubscription, Type> _subscriptionEventTypeLookup = new();
Aspire.Hosting.Analyzers (1)
AppHostAnalyzer.cs (1)
40modelNameOperations = new ConcurrentDictionary<ModelNameOperation, byte>();
Aspire.Hosting.Tests (1)
Dashboard\DashboardResourceTests.cs (1)
563private readonly ConcurrentDictionary<string, TestLogger> _loggers = new();
Aspire.StackExchange.Redis (1)
src\Vendoring\OpenTelemetry.Instrumentation.StackExchangeRedis\StackExchangeRedisConnectionInstrumentation.cs (1)
31= new();
BasicTestApp (1)
InteropTest\JavaScriptInterop.cs (1)
11public static ConcurrentDictionary<string, object[]> Invocations = new ConcurrentDictionary<string, object[]>();
DesignSurfaceExt (1)
TypeDiscoveryService.cs (1)
19private readonly ConcurrentDictionary<Type, ImmutableArray<Type>> _discoveredTypesCache = new();
dotnet-svcutil-lib (3)
FrameworkFork\System.ServiceModel\Internals\System\Runtime\InternalBufferManager.cs (1)
54private ConcurrentDictionary<int, string> _buffersPooled = new ConcurrentDictionary<int, string>();
FrameworkFork\System.ServiceModel\Internals\System\Runtime\TimeoutHelper.cs (1)
248new ConcurrentDictionary<long, Task<CancellationToken>>();
FrameworkFork\System.ServiceModel\System\ServiceModel\Channels\ServiceChannelProxy.cs (1)
283private static ConcurrentDictionary<Type, TaskCompletionSourceInfo> s_cache = new ConcurrentDictionary<Type, TaskCompletionSourceInfo>();
HtmlGenerationWebSite (1)
SignalTokenProviderService.cs (1)
12= new ConcurrentDictionary<object, ChangeTokenInfo>();
InMemory.FunctionalTests (2)
Http2\Http2TestBase.cs (1)
128protected readonly ConcurrentDictionary<int, TaskCompletionSource> _runningStreams = new ConcurrentDictionary<int, TaskCompletionSource>();
src\Servers\Kestrel\shared\test\Http3\Http3InMemory.cs (1)
82internal readonly ConcurrentDictionary<long, Http3StreamBase> _runningStreams = new ConcurrentDictionary<long, Http3StreamBase>();
Microsoft.AspNetCore.App.Analyzers (2)
Infrastructure\RouteUsageCache.cs (1)
26_lazyRoutePatterns = new();
RouteHandlers\RouteHandlerAnalyzer.cs (1)
53mapOperations = new ConcurrentDictionary<MapOperation, byte>();
Microsoft.AspNetCore.Authorization.Policy (1)
AuthorizationPolicyCache.cs (1)
22return new ConcurrentDictionary<Endpoint, AuthorizationPolicy>();
Microsoft.AspNetCore.Components (13)
BindConverter.cs (2)
1668private static readonly ConcurrentDictionary<Type, Delegate> _cache = new ConcurrentDictionary<Type, Delegate>(); 1857private static readonly ConcurrentDictionary<Type, Delegate> _cache = new ConcurrentDictionary<Type, Delegate>();
CascadingParameterState.cs (1)
17private static readonly ConcurrentDictionary<Type, CascadingParameterInfo[]> _cachedInfos = new();
CascadingValueSource.cs (1)
77_subscribers = new();
ChangeDetection.cs (1)
11private static readonly ConcurrentDictionary<Type, bool> _immutableObjectTypesCache = new();
ComponentFactory.cs (1)
19private static readonly ConcurrentDictionary<Type, ComponentTypeInfoCacheEntry> _cachedComponentTypeInfo = new();
DefaultComponentActivator.cs (1)
12private static readonly ConcurrentDictionary<Type, ObjectFactory> _cachedComponentTypeInfo = new();
Reflection\ComponentProperties.cs (1)
20= new ConcurrentDictionary<Type, WritersForType>();
RenderTree\EventArgsTypeCache.cs (1)
11private static readonly ConcurrentDictionary<MethodInfo, Type> Cache = new ConcurrentDictionary<MethodInfo, Type>();
RouteView.cs (1)
21private static readonly ConcurrentDictionary<Type, Type?> _layoutAttributeCache = new();
Routing\RouteTable.cs (1)
14private static readonly ConcurrentDictionary<(Type, string), InboundRouteEntry> _routeEntryCache = new();
Routing\RouteTableFactory.cs (1)
32private readonly ConcurrentDictionary<RouteKey, RouteTable> _cache = new();
Routing\UrlValueConstraint.cs (1)
17private static readonly ConcurrentDictionary<Type, UrlValueConstraint> _cachedInstances = new();
Microsoft.AspNetCore.Components.Authorization (1)
AttributeAuthorizeDataCache.cs (1)
11private static readonly ConcurrentDictionary<Type, IAuthorizeData[]?> _cache = new();
Microsoft.AspNetCore.Components.Endpoints (7)
Builder\RazorComponentsEndpointHttpContextExtensions.cs (1)
20private static readonly ConcurrentDictionary<Type, bool> AcceptsInteractiveRoutingCache = new();
FormMapping\FormDataMapperOptions.cs (1)
14private readonly ConcurrentDictionary<Type, FormDataConverter> _converters = new();
FormMapping\HttpContextFormValueMapper.cs (1)
21private static readonly ConcurrentDictionary<Type, FormValueSupplier> _cache = new();
Rendering\EndpointComponentState.cs (1)
17private static readonly ConcurrentDictionary<Type, StreamRenderingAttribute?> _streamRenderingAttributeByComponentType = new();
Rendering\SSRRenderModeBoundary.cs (1)
23private static readonly ConcurrentDictionary<Type, string> _componentTypeNameHashCache = new();
src\Shared\PropertyHelper\PropertyHelper.cs (2)
41private static readonly ConcurrentDictionary<Type, PropertyHelper[]> PropertiesCache = new(); 43private static readonly ConcurrentDictionary<Type, PropertyHelper[]> VisiblePropertiesCache = new();
Microsoft.AspNetCore.Components.Forms (4)
EditContextDataAnnotationsExtensions.cs (1)
62private static readonly ConcurrentDictionary<(Type ModelType, string FieldName), PropertyInfo?> _propertyInfoCache = new();
FieldIdentifier.cs (1)
19private static readonly ConcurrentDictionary<(Type ModelType, MemberInfo Member), Func<object, object>> _fieldAccessors = new();
src\Components\Shared\src\ExpressionFormatting\ExpressionFormatter.cs (2)
24private static readonly ConcurrentDictionary<MemberInfo, CapturedValueFormatter> s_capturedValueFormatterCache = new(); 25private static readonly ConcurrentDictionary<MethodInfo, MethodInfoData> s_methodInfoDataCache = new();
Microsoft.AspNetCore.Components.Forms.Tests (1)
FieldIdentifierTest.cs (1)
146var cache = new ConcurrentDictionary<(Type ModelType, MemberInfo FieldName), Func<object, object>>();
Microsoft.AspNetCore.Components.QuickGrid (1)
Infrastructure\AsyncQueryExecutorSupplier.cs (1)
24private static readonly ConcurrentDictionary<Type, bool> IsEntityFrameworkProviderTypeCache = new();
Microsoft.AspNetCore.Components.Server (4)
Circuits\CircuitRegistry.cs (1)
54ConnectedCircuits = new ConcurrentDictionary<CircuitId, CircuitHost>();
Circuits\RemoteJSRuntime.cs (1)
21private readonly ConcurrentDictionary<long, DotNetStreamReference> _pendingDotNetToJSStreams = new();
src\Components\Shared\src\ComponentParametersTypeCache.cs (1)
12private readonly ConcurrentDictionary<Key, Type?> _typeToKeyLookUp = new();
src\Components\Shared\src\RootComponentTypeCache.cs (1)
13private readonly ConcurrentDictionary<Key, Type?> _typeToKeyLookUp = new();
Microsoft.AspNetCore.Components.Web (3)
JSComponents\JSComponentInterop.cs (1)
26private static readonly ConcurrentDictionary<Type, ParameterTypeCache> ParameterTypeCaches = new();
src\Components\Shared\src\ExpressionFormatting\ExpressionFormatter.cs (2)
24private static readonly ConcurrentDictionary<MemberInfo, CapturedValueFormatter> s_capturedValueFormatterCache = new(); 25private static readonly ConcurrentDictionary<MethodInfo, MethodInfoData> s_methodInfoDataCache = new();
Microsoft.AspNetCore.Components.WebAssembly (5)
HotReload\HotReloadAgent.cs (2)
21private readonly ConcurrentDictionary<Guid, List<UpdateDelta>> _deltas = new(); 22private readonly ConcurrentDictionary<Assembly, Assembly> _appliedAssemblies = new();
Services\WebAssemblyConsoleLoggerProvider.cs (1)
23_loggers = new ConcurrentDictionary<string, WebAssemblyConsoleLogger<object>>();
src\Components\Shared\src\ComponentParametersTypeCache.cs (1)
12private readonly ConcurrentDictionary<Key, Type?> _typeToKeyLookUp = new();
src\Components\Shared\src\RootComponentTypeCache.cs (1)
13private readonly ConcurrentDictionary<Key, Type?> _typeToKeyLookUp = new();
Microsoft.AspNetCore.DataProtection (1)
KeyManagement\XmlKeyManager.cs (1)
61private readonly ConcurrentDictionary<Guid, Key> _knownKeyMap = new(); // Grows unboundedly, like the key ring
Microsoft.AspNetCore.Diagnostics.Middleware (1)
Logging\IncomingHttpRouteUtility.cs (1)
22private readonly ConcurrentDictionary<string, FrozenDictionary<string, DataClassification>> _parametersToRedactCache = new();
Microsoft.AspNetCore.Grpc.JsonTranscoding (3)
Internal\CallHandlers\CallHandlerDescriptorInfo.cs (1)
27PathDescriptorsCache = new ConcurrentDictionary<string, List<FieldDescriptor>?>();
src\Grpc\JsonTranscoding\src\Shared\DescriptorRegistry.cs (1)
14private readonly ConcurrentDictionary<Type, DescriptorBase> _typeDescriptorMap = new ConcurrentDictionary<Type, DescriptorBase>();
src\Grpc\JsonTranscoding\src\Shared\Legacy.cs (1)
375= new ConcurrentDictionary<Type, Dictionary<object, string>>();
Microsoft.AspNetCore.Grpc.Swagger (2)
src\Grpc\JsonTranscoding\src\Shared\DescriptorRegistry.cs (1)
14private readonly ConcurrentDictionary<Type, DescriptorBase> _typeDescriptorMap = new ConcurrentDictionary<Type, DescriptorBase>();
src\Grpc\JsonTranscoding\src\Shared\Legacy.cs (1)
375= new ConcurrentDictionary<Type, Dictionary<object, string>>();
Microsoft.AspNetCore.HeaderParsing (1)
HeaderRegistry.cs (1)
18private readonly ConcurrentDictionary<HeaderKeyIdentity, object> _headerKeys = new();
Microsoft.AspNetCore.Http.Abstractions (4)
Routing\EndpointMetadataCollection.cs (1)
41_cache = new ConcurrentDictionary<Type, object[]>();
Routing\RouteValueDictionary.cs (1)
44private static readonly ConcurrentDictionary<Type, PropertyHelper[]> _propertyCache = new ConcurrentDictionary<Type, PropertyHelper[]>();
src\Shared\PropertyHelper\PropertyHelper.cs (2)
41private static readonly ConcurrentDictionary<Type, PropertyHelper[]> PropertiesCache = new(); 43private static readonly ConcurrentDictionary<Type, PropertyHelper[]> VisiblePropertiesCache = new();
Microsoft.AspNetCore.Http.Connections (1)
Internal\HttpConnectionContext.cs (1)
180_items = new ConnectionItems(new ConcurrentDictionary<object, object?>());
Microsoft.AspNetCore.Http.Extensions (4)
src\Components\Endpoints\src\FormMapping\FormDataMapperOptions.cs (1)
14private readonly ConcurrentDictionary<Type, FormDataConverter> _converters = new();
src\Shared\ParameterBindingMethodCache.cs (3)
46private readonly ConcurrentDictionary<Type, Func<ParameterExpression, Expression, Expression>?> _stringMethodCallCache = new(); 47private readonly ConcurrentDictionary<Type, (Func<ParameterInfo, Expression>?, int)> _bindAsyncMethodCallCache = new(); 48private readonly ConcurrentDictionary<Type, (ConstructorInfo?, ConstructorParameter[])> _constructorCache = new();
Microsoft.AspNetCore.Mvc.Abstractions (3)
src\Shared\ParameterBindingMethodCache.cs (3)
46private readonly ConcurrentDictionary<Type, Func<ParameterExpression, Expression, Expression>?> _stringMethodCallCache = new(); 47private readonly ConcurrentDictionary<Type, (Func<ParameterInfo, Expression>?, int)> _bindAsyncMethodCallCache = new(); 48private readonly ConcurrentDictionary<Type, (ConstructorInfo?, ConstructorParameter[])> _constructorCache = new();
Microsoft.AspNetCore.Mvc.Core (15)
ActionConstraints\ActionConstraintCache.cs (1)
176new ConcurrentDictionary<ActionDescriptor, CacheEntry>();
Controllers\DefaultControllerPropertyActivator.cs (1)
15private readonly ConcurrentDictionary<Type, PropertyActivator<ControllerContext>[]> _activateActions = new();
Filters\MiddlewareFilterBuilder.cs (1)
21= new ConcurrentDictionary<Type, Lazy<RequestDelegate>>();
Infrastructure\AsyncEnumerableReader.cs (1)
34private readonly ConcurrentDictionary<Type, Func<object, CancellationToken, Task<ICollection>>?> _asyncEnumerableConverters = new();
Infrastructure\OrderedEndpointsSequenceProviderCache.cs (1)
11private readonly ConcurrentDictionary<IEndpointRouteBuilder, OrderedEndpointsSequenceProvider> _sequenceProviderCache = new();
Infrastructure\TypeActivatorCache.cs (1)
18new ConcurrentDictionary<Type, ObjectFactory>();
ModelBinding\Metadata\DefaultModelMetadataProvider.cs (1)
20private readonly ConcurrentDictionary<ModelMetadataIdentity, ModelMetadataCacheEntry> _modelMetadataCache = new();
ModelBinding\ModelBinderFactory.cs (1)
43_cache = new ConcurrentDictionary<Key, IModelBinder>();
ModelBinding\Validation\ClientValidatorCache.cs (1)
17private readonly ConcurrentDictionary<ModelMetadata, CacheEntry> _cacheEntries = new ConcurrentDictionary<ModelMetadata, CacheEntry>();
ModelBinding\Validation\DefaultCollectionValidationStrategy.cs (1)
49private readonly ConcurrentDictionary<Type, Func<object, IEnumerator>> _genericGetEnumeratorCache = new ConcurrentDictionary<Type, Func<object, IEnumerator>>();
ModelBinding\Validation\ValidatorCache.cs (1)
16private readonly ConcurrentDictionary<ModelMetadata, CacheEntry> _cacheEntries = new();
Routing\DynamicControllerEndpointSelectorCache.cs (2)
14private readonly ConcurrentDictionary<int, EndpointDataSource> _dataSourceCache = new(); 15private readonly ConcurrentDictionary<int, DynamicControllerEndpointSelector> _endpointSelectorCache = new();
src\Shared\PropertyHelper\PropertyHelper.cs (2)
41private static readonly ConcurrentDictionary<Type, PropertyHelper[]> PropertiesCache = new(); 43private static readonly ConcurrentDictionary<Type, PropertyHelper[]> VisiblePropertiesCache = new();
Microsoft.AspNetCore.Mvc.Formatters.Xml (4)
XmlDataContractSerializerInputFormatter.cs (1)
21private readonly ConcurrentDictionary<Type, object> _serializerCache = new ConcurrentDictionary<Type, object>();
XmlDataContractSerializerOutputFormatter.cs (1)
25private readonly ConcurrentDictionary<Type, object> _serializerCache = new ConcurrentDictionary<Type, object>();
XmlSerializerInputFormatter.cs (1)
21private readonly ConcurrentDictionary<Type, object> _serializerCache = new ConcurrentDictionary<Type, object>();
XmlSerializerOutputFormatter.cs (1)
25private readonly ConcurrentDictionary<Type, object> _serializerCache = new ConcurrentDictionary<Type, object>();
Microsoft.AspNetCore.Mvc.NewtonsoftJson (3)
BsonTempDataSerializer.cs (2)
27new ConcurrentDictionary<Type, Func<JArray, object>>(); 29new ConcurrentDictionary<Type, Func<JObject, object>>();
src\Mvc\Mvc.Core\src\Infrastructure\AsyncEnumerableReader.cs (1)
34private readonly ConcurrentDictionary<Type, Func<object, CancellationToken, Task<ICollection>>?> _asyncEnumerableConverters = new();
Microsoft.AspNetCore.Mvc.Razor (3)
DefaultTagHelperFactory.cs (1)
35_injectActions = new ConcurrentDictionary<Type, PropertyActivator<ViewContext>[]>();
RazorPageActivator.cs (1)
37_activationInfo = new ConcurrentDictionary<CacheKey, RazorPagePropertyActivator>();
TagHelpers\TagHelperComponentPropertyActivator.cs (1)
18private readonly ConcurrentDictionary<Type, PropertyActivator<ViewContext>[]> _propertiesToActivate = new();
Microsoft.AspNetCore.Mvc.RazorPages (2)
Infrastructure\DynamicPageEndpointSelectorCache.cs (2)
15private readonly ConcurrentDictionary<int, EndpointDataSource> _dataSourceCache = new(); 16private readonly ConcurrentDictionary<int, DynamicPageEndpointSelector> _endpointSelectorCache = new();
Microsoft.AspNetCore.Mvc.TagHelpers (1)
Cache\DistributedCacheTagHelperService.cs (1)
61_workers = new ConcurrentDictionary<CacheTagKey, Task<IHtmlContent>>();
Microsoft.AspNetCore.Mvc.TagHelpers.Test (4)
JavaScriptResourcesTest.cs (4)
19var cache = new ConcurrentDictionary<string, string>(); 36var cache = new ConcurrentDictionary<string, string>(); 61var cache = new ConcurrentDictionary<string, string>(); 81var cache = new ConcurrentDictionary<string, string>();
Microsoft.AspNetCore.Mvc.ViewFeatures (5)
CachedExpressionCompiler.cs (2)
35new ConcurrentDictionary<MemberInfo, Func<TModel, object>>(); 41new ConcurrentDictionary<MemberInfo, Func<object, TResult>>();
HtmlAttributePropertyHelper.cs (1)
16new ConcurrentDictionary<Type, HtmlAttributePropertyHelper[]>();
ViewComponents\DefaultViewComponentFactory.cs (1)
36_injectActions = new ConcurrentDictionary<Type, PropertyActivator<ViewComponentContext>[]>();
ViewComponents\ViewComponentInvokerCache.cs (1)
77new ConcurrentDictionary<ViewComponentDescriptor, ObjectMethodExecutor>();
Microsoft.AspNetCore.OpenApi (6)
Services\OpenApiDocumentService.cs (1)
50private readonly ConcurrentDictionary<string, OpenApiOperationTransformerContext> _operationTransformerContextCache = new();
Services\Schemas\OpenApiSchemaStore.cs (2)
18private readonly ConcurrentDictionary<OpenApiSchemaKey, JsonNode> _schemas = new() 53private readonly ConcurrentDictionary<string, int> _referenceIdCounter = new();
src\Shared\ParameterBindingMethodCache.cs (3)
46private readonly ConcurrentDictionary<Type, Func<ParameterExpression, Expression, Expression>?> _stringMethodCallCache = new(); 47private readonly ConcurrentDictionary<Type, (Func<ParameterInfo, Expression>?, int)> _bindAsyncMethodCallCache = new(); 48private readonly ConcurrentDictionary<Type, (ConstructorInfo?, ConstructorParameter[])> _constructorCache = new();
Microsoft.AspNetCore.OutputCaching (1)
DispatcherExtensions.cs (1)
10private readonly ConcurrentDictionary<TKey, Task<TValue?>> _workers = new();
Microsoft.AspNetCore.Routing (4)
DefaultLinkGenerator.cs (1)
55return new ConcurrentDictionary<RouteEndpoint, TemplateBinder>();
DefaultLinkParser.cs (1)
41return new ConcurrentDictionary<RouteEndpoint, MatcherState>();
src\Shared\PropertyHelper\PropertyHelper.cs (2)
41private static readonly ConcurrentDictionary<Type, PropertyHelper[]> PropertiesCache = new(); 43private static readonly ConcurrentDictionary<Type, PropertyHelper[]> VisiblePropertiesCache = new();
Microsoft.AspNetCore.Routing.Abstractions (2)
src\Shared\PropertyHelper\PropertyHelper.cs (2)
41private static readonly ConcurrentDictionary<Type, PropertyHelper[]> PropertiesCache = new(); 43private static readonly ConcurrentDictionary<Type, PropertyHelper[]> VisiblePropertiesCache = new();
Microsoft.AspNetCore.Server.HttpSys (1)
NativeInterop\DisconnectListener.cs (1)
12private readonly ConcurrentDictionary<ulong, ConnectionCancellation> _connectionCancellationTokens = new();
Microsoft.AspNetCore.Server.Kestrel.Core (3)
Internal\Infrastructure\ConnectionManager.cs (1)
14private readonly ConcurrentDictionary<long, ConnectionReference> _connectionReferences = new ConcurrentDictionary<long, ConnectionReference>();
Internal\Infrastructure\TransportConnectionManager.cs (1)
14private readonly ConcurrentDictionary<long, ConnectionReference> _connectionReferences = new ConcurrentDictionary<long, ConnectionReference>();
Internal\WebTransport\WebTransportSession.cs (1)
24private readonly ConcurrentDictionary<long, WebTransportStream> _openStreams = new();
Microsoft.AspNetCore.Server.Kestrel.Microbenchmarks (1)
src\Servers\Kestrel\shared\test\Http3\Http3InMemory.cs (1)
82internal readonly ConcurrentDictionary<long, Http3StreamBase> _runningStreams = new ConcurrentDictionary<long, Http3StreamBase>();
Microsoft.AspNetCore.Shared.Tests (2)
src\Shared\PropertyHelper\PropertyHelper.cs (2)
41private static readonly ConcurrentDictionary<Type, PropertyHelper[]> PropertiesCache = new(); 43private static readonly ConcurrentDictionary<Type, PropertyHelper[]> VisiblePropertiesCache = new();
Microsoft.AspNetCore.SignalR.Core (2)
src\SignalR\common\Shared\ClientResultsManager.cs (1)
16private readonly ConcurrentDictionary<string, (Type Type, string ConnectionId, object Tcs, Action<object, CompletionMessage> Complete)> _pendingInvocations = new();
StreamTracker.cs (1)
19private readonly ConcurrentDictionary<string, IStreamConverter> _lookup = new ConcurrentDictionary<string, IStreamConverter>();
Microsoft.AspNetCore.SignalR.StackExchangeRedis (2)
Internal\AckHandler.cs (1)
11private readonly ConcurrentDictionary<int, AckInfo> _acks = new ConcurrentDictionary<int, AckInfo>();
src\SignalR\common\Shared\ClientResultsManager.cs (1)
16private readonly ConcurrentDictionary<string, (Type Type, string ConnectionId, object Tcs, Action<object, CompletionMessage> Complete)> _pendingInvocations = new();
Microsoft.AspNetCore.SignalR.StackExchangeRedis.Tests (1)
TestConnectionMultiplexer.cs (1)
240new ConcurrentDictionary<RedisChannel, List<(int, Action<RedisChannel, RedisValue>)>>();
Microsoft.Build (25)
BackEnd\Components\Caching\ResultsCache.cs (1)
40_resultsByConfiguration = new ConcurrentDictionary<int, BuildResult>();
BackEnd\Components\Communications\NodeProviderOutOfProc.cs (1)
180_nodeContexts = new ConcurrentDictionary<int, NodeContext>();
BackEnd\Components\Communications\NodeProviderOutOfProcBase.cs (1)
68private readonly ConcurrentDictionary<string, byte /*void*/> _processesToIgnore = new();
BackEnd\Components\Communications\TranslatorExtensions.cs (1)
23private static Lazy<ConcurrentDictionary<Type, ConstructorInfo>> parameterlessConstructorCache = new Lazy<ConcurrentDictionary<Type, ConstructorInfo>>(() => new ConcurrentDictionary<Type, ConstructorInfo>());
BackEnd\Components\Logging\LoggingService.cs (2)
298_projectFileMap = new ConcurrentDictionary<int, string>(); 752warningsByProject ??= new ConcurrentDictionary<WarningsConfigKey, ISet<string>>();
BackEnd\Components\ProjectCache\ProjectCacheService.cs (1)
50private readonly ConcurrentDictionary<BuildRequestConfiguration, IReadOnlyDictionary<string, string>> _globalPropertiesPerConfiguration = new();
BackEnd\Components\SdkResolution\CachingSdkResolverLoader.cs (1)
25private readonly ConcurrentDictionary<SdkResolverManifest, IReadOnlyList<SdkResolver>> _resolversByManifest = new();
BackEnd\Components\SdkResolution\CachingSdkResolverService.cs (1)
22private readonly ConcurrentDictionary<int, ConcurrentDictionary<string, Lazy<SdkResult>>> _cache = new ConcurrentDictionary<int, ConcurrentDictionary<string, Lazy<SdkResult>>>();
BackEnd\Components\SdkResolution\SdkResolverService.cs (1)
41private readonly ConcurrentDictionary<int, ConcurrentDictionary<SdkResolver, object>> _resolverStateBySubmission = new ConcurrentDictionary<int, ConcurrentDictionary<SdkResolver, object>>();
BuildCheck\Infrastructure\BuildCheckManagerProvider.cs (2)
504private readonly ConcurrentDictionary<int, string> _projectsByInstanceId = new(); 505private readonly ConcurrentDictionary<int, string> _projectsByEvaluationId = new();
CachingFileSystemWrapper.cs (2)
16private readonly ConcurrentDictionary<string, bool> _existenceCache = new ConcurrentDictionary<string, bool>(); 17private readonly ConcurrentDictionary<string, DateTime> _lastWriteTimeCache = new ConcurrentDictionary<string, DateTime>();
Evaluation\ConditionEvaluator.cs (1)
169private static volatile ConcurrentDictionary<int, ExpressionTreeForCurrentOptionsWithSize> s_cachedExpressionTrees = new ConcurrentDictionary<int, ExpressionTreeForCurrentOptionsWithSize>();
Evaluation\Context\EvaluationContext.cs (1)
69FileEntryExpansionCache = fileEntryExpansionCache ?? new ConcurrentDictionary<string, IReadOnlyList<string>>();
FrameworkLocationHelper.cs (2)
1326this._pathsToDotNetFramework = new ConcurrentDictionary<DotNetFrameworkArchitecture, string>(); 1327this._pathsToDotNetFrameworkSdkTools = new ConcurrentDictionary<Version, string>();
Graph\GraphBuilder.cs (2)
53private ConcurrentDictionary<ConfigurationMetadata, Lazy<ProjectInstance>> _platformNegotiationInstancesCache = new(); 648new ConcurrentDictionary<(ProjectGraphNode, ProjectGraphNode), ProjectItemInstance>();
Graph\ProjectGraph.cs (1)
503var nodeIds = new ConcurrentDictionary<ProjectGraphNode, string>();
TypeLoader.cs (3)
34private static ConcurrentDictionary<Func<Type, object, bool>, ConcurrentDictionary<AssemblyLoadInfo, AssemblyInfoToLoadedTypes>> s_cacheOfLoadedTypesByFilter = new ConcurrentDictionary<Func<Type, object, bool>, ConcurrentDictionary<AssemblyLoadInfo, AssemblyInfoToLoadedTypes>>(); 39private static ConcurrentDictionary<Func<Type, object, bool>, ConcurrentDictionary<AssemblyLoadInfo, AssemblyInfoToLoadedTypes>> s_cacheOfReflectionOnlyLoadedTypesByFilter = new ConcurrentDictionary<Func<Type, object, bool>, ConcurrentDictionary<AssemblyLoadInfo, AssemblyInfoToLoadedTypes>>(); 246cache.GetOrAdd(_isDesiredType, (_) => new ConcurrentDictionary<AssemblyLoadInfo, AssemblyInfoToLoadedTypes>());
Utilities\EngineFileUtilities.cs (1)
586private readonly Lazy<ConcurrentDictionary<string, bool>> existenceCache = new Lazy<ConcurrentDictionary<string, bool>>(() => new ConcurrentDictionary<string, bool>(), true);
Microsoft.Build.Engine.OM.UnitTests (2)
CachingFileSystemWrapper.cs (2)
16private readonly ConcurrentDictionary<string, bool> _existenceCache = new ConcurrentDictionary<string, bool>(); 17private readonly ConcurrentDictionary<string, DateTime> _lastWriteTimeCache = new ConcurrentDictionary<string, DateTime>();
Microsoft.Build.Engine.UnitTests (2)
FileMatcher_Tests.cs (1)
134var fileMatcherWithCache = new FileMatcher(FileSystems.Default, new ConcurrentDictionary<string, IReadOnlyList<string>>());
InternalEngineHelpers.cs (1)
44public ConcurrentDictionary<string, int> ResolvedCalls { get; } = new ConcurrentDictionary<string, int>();
Microsoft.Build.Framework (1)
FileClassifier.cs (1)
83private readonly ConcurrentDictionary<string, string> _knownImmutableDirectories = new();
Microsoft.Build.Tasks.Core (4)
AssemblyDependency\ResolveAssemblyReference.cs (1)
2373? new ConcurrentDictionary<string, AssemblyMetadata>()
CachingFileSystemWrapper.cs (2)
16private readonly ConcurrentDictionary<string, bool> _existenceCache = new ConcurrentDictionary<string, bool>(); 17private readonly ConcurrentDictionary<string, DateTime> _lastWriteTimeCache = new ConcurrentDictionary<string, DateTime>();
RoslynCodeTaskFactory\RoslynCodeTaskFactory.cs (1)
87private static readonly ConcurrentDictionary<RoslynCodeTaskFactoryTaskInfo, Assembly> CompiledAssemblyCache = new ConcurrentDictionary<RoslynCodeTaskFactoryTaskInfo, Assembly>();
Microsoft.Build.UnitTests.Shared (4)
MockEngine.cs (1)
42private readonly ConcurrentDictionary<object, object> _objectCache = new ConcurrentDictionary<object, object>();
ObjectModelHelpers.cs (3)
2166public ConcurrentDictionary<string, int> ExistenceChecks { get; } = new(); 2167public ConcurrentDictionary<string, int> Enumerations { get; } = new(); 2215public ConcurrentDictionary<string, int> ExistenceChecks { get; } = new ConcurrentDictionary<string, int>();
Microsoft.Build.Utilities.Core (4)
CachingFileSystemWrapper.cs (2)
16private readonly ConcurrentDictionary<string, bool> _existenceCache = new ConcurrentDictionary<string, bool>(); 17private readonly ConcurrentDictionary<string, DateTime> _lastWriteTimeCache = new ConcurrentDictionary<string, DateTime>();
FrameworkLocationHelper.cs (2)
1326this._pathsToDotNetFramework = new ConcurrentDictionary<DotNetFrameworkArchitecture, string>(); 1327this._pathsToDotNetFrameworkSdkTools = new ConcurrentDictionary<Version, string>();
Microsoft.CodeAnalysis (21)
CodeGen\ArrayMembers.cs (1)
100new ConcurrentDictionary<(byte, IReferenceOrISignature), ArrayMethod>();
CodeGen\CompilationTestData.cs (1)
35public readonly ConcurrentDictionary<IMethodSymbolInternal, MethodData> Methods = new ConcurrentDictionary<IMethodSymbolInternal, MethodData>();
CodeGen\PrivateImplementationDetails.cs (4)
82private readonly ConcurrentDictionary<int, InstrumentationPayloadRootField> _instrumentationPayloadRootFields = new ConcurrentDictionary<int, InstrumentationPayloadRootField>(); 87new ConcurrentDictionary<string, Cci.IMethodDefinition>(); 91private readonly ConcurrentDictionary<string, Cci.INamespaceTypeDefinition> _synthesizedTopLevelTypes = new ConcurrentDictionary<string, Cci.INamespaceTypeDefinition>(); 95private readonly ConcurrentDictionary<(uint Size, ushort Alignment), Cci.ITypeReference> _proxyTypes = new ConcurrentDictionary<(uint Size, ushort Alignment), Cci.ITypeReference>();
CodeGen\TokenMap.cs (1)
25private readonly ConcurrentDictionary<IReferenceOrISignature, uint> _itemIdentityToToken = new();
Diagnostic\CommonMessageProvider.cs (1)
21private static readonly ConcurrentDictionary<(string prefix, int code), string> s_errorIdCache = new ConcurrentDictionary<(string prefix, int code), string>();
DiagnosticAnalyzer\AnalyzerDriver.cs (5)
418_lazyGeneratedCodeFilesMap = new ConcurrentDictionary<SyntaxTree, bool>(); 420_lazyIsGeneratedCodeSymbolMap = new ConcurrentDictionary<ISymbol, bool>(); 421_lazyTreesWithHiddenRegionsMap = new ConcurrentDictionary<SyntaxTree, bool>(); 422_lazySuppressedAnalyzersForTreeMap = new ConcurrentDictionary<SyntaxTree, ImmutableHashSet<DiagnosticAnalyzer>>(); 435_lazyPerSymbolAnalyzerActionsCache = new ConcurrentDictionary<(INamespaceOrTypeSymbol, DiagnosticAnalyzer), IGroupedAnalyzerActions>();
DiagnosticAnalyzer\AnalyzerExecutor.cs (2)
122var analyzerExecutionTimeMap = logExecutionTime ? new ConcurrentDictionary<DiagnosticAnalyzer, StrongBox<long>>() : null; 1506Interlocked.CompareExchange(ref _lazyControlFlowGraphMap, new ConcurrentDictionary<IOperation, ControlFlowGraph>(), null);
DiagnosticAnalyzer\CachingSemanticModelProvider.cs (1)
64_semanticModelsMap = new ConcurrentDictionary<SyntaxTree, SemanticModel>();
DiagnosticAnalyzer\ShadowCopyAnalyzerAssemblyLoader.cs (2)
39private readonly ConcurrentDictionary<Guid, Task<string>> _mvidPathMap = new ConcurrentDictionary<Guid, Task<string>>(); 40private readonly ConcurrentDictionary<(Guid, string), Task<string>> _mvidSatelliteAssemblyPathMap = new ConcurrentDictionary<(Guid, string), Task<string>>();
DiagnosticAnalyzer\SuppressMessageAttributeState.cs (1)
108_localSuppressionsBySymbol = new ConcurrentDictionary<ISymbol, ImmutableDictionary<string, SuppressMessageInfo>>();
Emit\CommonPEModuleBuilder.cs (1)
959Interlocked.CompareExchange(ref _lazySynthesizedNamespaceMembers, new ConcurrentDictionary<INamespaceSymbolInternal, ConcurrentQueue<INamespaceOrTypeSymbolInternal>>(), null);
MetadataReader\PEModule.cs (1)
2650new ConcurrentDictionary<TypeDefinitionHandle, AttributeInfo>(),
Microsoft.CodeAnalysis.CodeStyle (8)
src\Analyzers\Core\Analyzers\IDEDiagnosticIdToOptionMappingHelper.cs (4)
23private static readonly ConcurrentDictionary<string, ImmutableHashSet<IOption2>> s_diagnosticIdToOptionMap = new(); 24private static readonly ConcurrentDictionary<string, ConcurrentDictionary<string, ImmutableHashSet<IOption2>>> s_diagnosticIdToLanguageSpecificOptionsMap = new(); 25private static readonly ConcurrentDictionary<string, PerLanguageOption2<bool>> s_diagnosticIdToFadingOptionMap = new(); 71var map = s_diagnosticIdToLanguageSpecificOptionsMap.GetOrAdd(language, _ => new ConcurrentDictionary<string, ImmutableHashSet<IOption2>>());
src\Analyzers\Core\Analyzers\MakeFieldReadonly\AbstractMakeFieldReadonlyDiagnosticAnalyzer.cs (1)
42var fieldStateMap = new ConcurrentDictionary<IFieldSymbol, (bool isCandidate, bool written)>();
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Simplification\SpecialTypeAnnotation.cs (2)
14private static readonly ConcurrentDictionary<SpecialType, string> s_fromSpecialTypes = new(); 15private static readonly ConcurrentDictionary<string, SpecialType> s_toSpecialTypes = new();
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Utilities\AliasSymbolCache.cs (1)
52var treeMap = s_treeAliasMap.GetValue(semanticModel.Compilation, static _ => new TreeMap());
Microsoft.CodeAnalysis.CodeStyle.Fixes (2)
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Simplification\AbstractSimplificationService.cs (2)
115var reducedNodesMap = new ConcurrentDictionary<SyntaxNode, SyntaxNode>(); 116var reducedTokensMap = new ConcurrentDictionary<SyntaxToken, SyntaxToken>();
Microsoft.CodeAnalysis.CSharp (11)
Compilation\CSharpCompilation.cs (1)
1495Interlocked.CompareExchange(ref _externAliasTargets, new ConcurrentDictionary<string, NamespaceSymbol>(), null);
Emitter\Model\PEModuleBuilder.cs (1)
29protected readonly ConcurrentDictionary<Symbol, Cci.IModuleReference> AssemblyOrModuleSymbolToModuleRefMap = new ConcurrentDictionary<Symbol, Cci.IModuleReference>();
FlowAnalysis\NullableWalker.cs (1)
42Data = new ConcurrentDictionary<object, NullableWalker.Data>();
Symbols\AnonymousTypes\AnonymousTypeManager.Templates.cs (3)
92private readonly ConcurrentDictionary<Location, bool> _sourceLocationsSeen = new ConcurrentDictionary<Location, bool>(); 128? new ConcurrentDictionary<string, AnonymousTypeTemplateSymbol>() 150? new ConcurrentDictionary<SynthesizedDelegateKey, AnonymousDelegateTemplateSymbol>()
Symbols\MetadataOrSourceAssemblySymbol.cs (1)
273Interlocked.CompareExchange(ref _assembliesToWhichInternalAccessHasBeenAnalyzed, new ConcurrentDictionary<AssemblySymbol, IVTConclusion>(), null);
Symbols\NonMissingAssemblySymbol.cs (1)
33new ConcurrentDictionary<MetadataTypeName.Key, NamedTypeSymbol>();
Symbols\Source\SourceAssemblySymbol.cs (3)
96private readonly ConcurrentDictionary<FieldSymbol, bool> _unassignedFieldsMap = new ConcurrentDictionary<FieldSymbol, bool>(); 2163Interlocked.CompareExchange(ref _optimisticallyGrantedInternalsAccess, new ConcurrentDictionary<AssemblySymbol, bool>(), null); 2333keys = new ConcurrentDictionary<ImmutableArray<byte>, Tuple<Location, String>>();
Microsoft.CodeAnalysis.CSharp.CodeStyle (3)
src\Analyzers\CSharp\Analyzers\UseIndexOrRangeOperator\CSharpUseIndexOperatorDiagnosticAnalyzer.InfoCache.cs (1)
35private readonly ConcurrentDictionary<IMethodSymbol, MemberInfo> _methodToMemberInfo = new();
src\Analyzers\CSharp\Analyzers\UseIndexOrRangeOperator\CSharpUseRangeOperatorDiagnosticAnalyzer.InfoCache.cs (1)
31private readonly ConcurrentDictionary<IMethodSymbol, MemberInfo> _methodToMemberInfo = new();
src\Analyzers\CSharp\Analyzers\UsePrimaryConstructor\CSharpUsePrimaryConstructorDiagnosticAnalyzer.cs (1)
79var namedTypeToAnalyzer = new ConcurrentDictionary<INamedTypeSymbol, Analyzer>();
Microsoft.CodeAnalysis.CSharp.Emit3.UnitTests (1)
Diagnostics\DiagnosticAnalyzerTests.cs (1)
4054private readonly ConcurrentDictionary<SyntaxTree, SemanticModel> _cache = new ConcurrentDictionary<SyntaxTree, SemanticModel>();
Microsoft.CodeAnalysis.CSharp.Features (3)
src\Analyzers\CSharp\Analyzers\UseIndexOrRangeOperator\CSharpUseIndexOperatorDiagnosticAnalyzer.InfoCache.cs (1)
35private readonly ConcurrentDictionary<IMethodSymbol, MemberInfo> _methodToMemberInfo = new();
src\Analyzers\CSharp\Analyzers\UseIndexOrRangeOperator\CSharpUseRangeOperatorDiagnosticAnalyzer.InfoCache.cs (1)
31private readonly ConcurrentDictionary<IMethodSymbol, MemberInfo> _methodToMemberInfo = new();
src\Analyzers\CSharp\Analyzers\UsePrimaryConstructor\CSharpUsePrimaryConstructorDiagnosticAnalyzer.cs (1)
79var namedTypeToAnalyzer = new ConcurrentDictionary<INamedTypeSymbol, Analyzer>();
Microsoft.CodeAnalysis.CSharp.Features.UnitTests (1)
Diagnostics\Suppression\RemoveUnnecessaryPragmaSuppressionsTests.cs (1)
68var localsToIsAssignedMap = new ConcurrentDictionary<ILocalSymbol, bool>();
Microsoft.CodeAnalysis.CSharp.Scripting.UnitTests (1)
ObjectFormatterTests.cs (1)
688var obj = new ConcurrentDictionary<string, int>();
Microsoft.CodeAnalysis.EditorFeatures (1)
IntelliSense\AsyncCompletion\ItemManager.CompletionListUpdater.cs (1)
251var includedDefaults = new ConcurrentDictionary<string, MatchResult>();
Microsoft.CodeAnalysis.EditorFeatures.Wpf (2)
Lightup\LightupHelpers.cs (2)
15private static readonly ConcurrentDictionary<Type, ConcurrentDictionary<Type, bool>> s_supportedObjectWrappers = new(); 31var wrappedObject = s_supportedObjectWrappers.GetOrAdd(underlyingType, static _ => new ConcurrentDictionary<Type, bool>());
Microsoft.CodeAnalysis.ExpressionEvaluator.ResultProvider.Utilities (1)
Debugger\Engine\DkmClrAppDomain.cs (1)
36TypeToEvalAttributesMap = new ConcurrentDictionary<Type, ReadOnlyCollection<DkmClrEvalAttribute>>();
Microsoft.CodeAnalysis.Features (9)
CodeFixes\Suppression\AbstractSuppressionBatchFixAllProvider.cs (2)
254var documentIdToChangedDocuments = new ConcurrentDictionary<DocumentId, ConcurrentBag<(CodeAction, Document)>>(); 283var documentIdToFinalText = new ConcurrentDictionary<DocumentId, SourceText>();
Organizing\AbstractOrganizingService.cs (1)
35var map = new ConcurrentDictionary<Type, IEnumerable<ISyntaxOrganizer>>();
Shared\Extensions\ISymbolExtensions_Sorting.cs (1)
36var symbolToParameterTypeNames = new ConcurrentDictionary<TSymbol, string[]>();
src\Analyzers\Core\Analyzers\IDEDiagnosticIdToOptionMappingHelper.cs (4)
23private static readonly ConcurrentDictionary<string, ImmutableHashSet<IOption2>> s_diagnosticIdToOptionMap = new(); 24private static readonly ConcurrentDictionary<string, ConcurrentDictionary<string, ImmutableHashSet<IOption2>>> s_diagnosticIdToLanguageSpecificOptionsMap = new(); 25private static readonly ConcurrentDictionary<string, PerLanguageOption2<bool>> s_diagnosticIdToFadingOptionMap = new(); 71var map = s_diagnosticIdToLanguageSpecificOptionsMap.GetOrAdd(language, _ => new ConcurrentDictionary<string, ImmutableHashSet<IOption2>>());
src\Analyzers\Core\Analyzers\MakeFieldReadonly\AbstractMakeFieldReadonlyDiagnosticAnalyzer.cs (1)
42var fieldStateMap = new ConcurrentDictionary<IFieldSymbol, (bool isCandidate, bool written)>();
Microsoft.CodeAnalysis.LanguageServer (1)
LanguageServer\Handler\DebugConfiguration\ProjectTargetFrameworkManager.cs (1)
17private readonly ConcurrentDictionary<ProjectId, string?> _projectToTargetFrameworkIdentifer = new();
Microsoft.CodeAnalysis.LanguageServer.Protocol (3)
Protocol\Converters\SumConverter.cs (1)
183private static readonly ConcurrentDictionary<Type, SumConverter.SumTypeInfoCache> SumTypeCache = new ConcurrentDictionary<Type, SumConverter.SumTypeInfoCache>();
Protocol\Internal\Efficiency\OptimizedVSCompletionListJsonConverter.cs (1)
17private static readonly ConcurrentDictionary<ImageId, string> IconRawJson = new ConcurrentDictionary<ImageId, string>();
src\LanguageServer\Microsoft.CommonLanguageServerProtocol.Framework\RequestExecutionQueue.cs (1)
197var concurrentlyExecutingTasks = new ConcurrentDictionary<Task, CancellationTokenSource>();
Microsoft.CodeAnalysis.LanguageServer.UnitTests (1)
LspFileChangeWatcherTests.cs (1)
120public readonly ConcurrentDictionary<string, Registration> Registrations = new();
Microsoft.CodeAnalysis.Remote.ServiceHub (1)
Host\SolutionAssetCache.cs (1)
46private readonly ConcurrentDictionary<Checksum, Entry> _assets = new();
Microsoft.CodeAnalysis.Remote.Workspaces (1)
Serialization\MessagePackFormatters.cs (1)
58private readonly ConcurrentDictionary<Guid, ProjectId> _projectIds = new ConcurrentDictionary<Guid, ProjectId>();
Microsoft.CodeAnalysis.Test.Utilities (2)
Diagnostics\CommonDiagnosticAnalyzers.cs (2)
1252_controlFlowGraphMapOpt = verifyGetControlFlowGraph ? new ConcurrentDictionary<IOperation, (ControlFlowGraph, ISymbol)>() : null; 1980var seenOperationContainers = new ConcurrentDictionary<OperationAnalysisContext, ISet<ISymbol>>();
Microsoft.CodeAnalysis.UnitTests (2)
InternalUtilities\ConcurrentDictionaryExtensionsTests.cs (2)
17var dictionary = new ConcurrentDictionary<int, int>(); 30var dictionary = new ConcurrentDictionary<int, object>();
Microsoft.CodeAnalysis.VisualBasic (20)
Binding\BinderFactory.vb (1)
43Me._cache = New ConcurrentDictionary(Of ValueTuple(Of VisualBasicSyntaxNode, Byte), Binder)
BoundTree\BoundAddressOfOperator.vb (1)
14Private ReadOnly _delegateResolutionResultCache As New ConcurrentDictionary(Of TypeSymbol, Binder.DelegateResolutionResult)()
BoundTree\UnboundLambda.vb (2)
220Public ReadOnly InferredReturnType As New ConcurrentDictionary(Of TargetSignature, KeyValuePair(Of TypeSymbol, ReadOnlyBindingDiagnostic(Of AssemblySymbol)))() 221Public ReadOnly BoundLambdas As New ConcurrentDictionary(Of TargetSignature, BoundLambda)()
Compilation\ClsComplianceChecker.vb (1)
48Me._declaredOrInheritedCompliance = New ConcurrentDictionary(Of Symbol, Compliance)()
Compilation\SyntaxTreeSemanticModel.vb (1)
34Private ReadOnly _semanticModelCache As New ConcurrentDictionary(Of Binder, MemberSemanticModel)()
Emit\SymbolTranslator.vb (2)
18Protected ReadOnly m_AssemblyOrModuleSymbolToModuleRefMap As New ConcurrentDictionary(Of Symbol, Microsoft.Cci.IModuleReference)() 19Private ReadOnly _genericInstanceMap As New ConcurrentDictionary(Of Symbol, Object)()
Symbols\AnonymousTypes\AnonymousTypeManager_Templates.vb (3)
28Private ReadOnly _sourceLocationsSeen As New ConcurrentDictionary(Of Location, Boolean) 56New ConcurrentDictionary(Of String, AnonymousTypeTemplateSymbol), 74New ConcurrentDictionary(Of String, AnonymousDelegateTemplateSymbol),
Symbols\MetadataOrSourceAssemblySymbol.vb (1)
172Interlocked.CompareExchange(_assembliesToWhichInternalAccessHasBeenAnalyzed, New ConcurrentDictionary(Of AssemblySymbol, IVTConclusion), Nothing)
Symbols\NonMissingAssemblySymbol.vb (1)
33Private ReadOnly _emittedNameToTypeMap As New ConcurrentDictionary(Of MetadataTypeName.Key, NamedTypeSymbol)()
Symbols\Retargeting\RetargetingAssemblySymbol.vb (1)
71Friend ReadOnly m_NoPiaUnificationMap As New ConcurrentDictionary(Of NamedTypeSymbol, NamedTypeSymbol)()
Symbols\Retargeting\RetargetingModuleSymbol.vb (1)
209Dim symbolMap = New ConcurrentDictionary(Of NamedTypeSymbol, NamedTypeSymbol)()
Symbols\Retargeting\RetargetingSymbolTranslator.vb (1)
27Private ReadOnly _symbolMap As New ConcurrentDictionary(Of Symbol, Symbol)()
Symbols\Source\SourceAssemblySymbol.vb (2)
1007keys = New ConcurrentDictionary(Of ImmutableArray(Of Byte), Tuple(Of Location, String)) 1656Interlocked.CompareExchange(_optimisticallyGrantedInternalsAccess, New ConcurrentDictionary(Of AssemblySymbol, Boolean), Nothing)
Symbols\Source\SourceModuleSymbol.vb (1)
68Private ReadOnly _sourceFileMap As New ConcurrentDictionary(Of SyntaxTree, SourceFile)
Symbols\Source\SourceNamedTypeSymbol.vb (1)
2576New ConcurrentDictionary(Of PropertySymbol, SynthesizedOverridingWithEventsProperty),
Microsoft.CodeAnalysis.VisualBasic.Semantic.UnitTests (1)
Diagnostics\DiagnosticAnalyzerTests.vb (1)
1707Private ReadOnly _cache As New ConcurrentDictionary(Of SyntaxTree, SemanticModel)()
Microsoft.CodeAnalysis.Workspaces (9)
CaseCorrection\AbstractCaseCorrectionService.cs (1)
49var replacements = new ConcurrentDictionary<SyntaxToken, SyntaxToken>();
src\Compilers\Core\Portable\DiagnosticAnalyzer\ShadowCopyAnalyzerAssemblyLoader.cs (2)
39private readonly ConcurrentDictionary<Guid, Task<string>> _mvidPathMap = new ConcurrentDictionary<Guid, Task<string>>(); 40private readonly ConcurrentDictionary<(Guid, string), Task<string>> _mvidSatelliteAssemblyPathMap = new ConcurrentDictionary<(Guid, string), Task<string>>();
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Simplification\SpecialTypeAnnotation.cs (2)
14private static readonly ConcurrentDictionary<SpecialType, string> s_fromSpecialTypes = new(); 15private static readonly ConcurrentDictionary<string, SpecialType> s_toSpecialTypes = new();
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Utilities\AliasSymbolCache.cs (1)
52var treeMap = s_treeAliasMap.GetValue(semanticModel.Compilation, static _ => new TreeMap());
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Simplification\AbstractSimplificationService.cs (2)
115var reducedNodesMap = new ConcurrentDictionary<SyntaxNode, SyntaxNode>(); 116var reducedTokensMap = new ConcurrentDictionary<SyntaxToken, SyntaxToken>();
Workspace\Host\Documentation\DocumentationProviderServiceFactory.cs (1)
28new();
Microsoft.CommonLanguageServerProtocol.Framework.Package (1)
RequestExecutionQueue.cs (1)
197var concurrentlyExecutingTasks = new ConcurrentDictionary<Task, CancellationTokenSource>();
Microsoft.DotNet.Build.Tasks.Packaging (1)
PackageIndex.cs (1)
22static ConcurrentDictionary<string, PackageIndex> s_indexCache = new ConcurrentDictionary<string, PackageIndex>();
Microsoft.DotNet.XUnitAssert.Tests (2)
EqualityAssertsTests.cs (2)
1170 var actual = new ConcurrentDictionary<string, string> { ["foo"] = "baz" }; 3412 var actual = new ConcurrentDictionary<string, string> { ["foo"] = "baz" };
Microsoft.Extensions.Caching.Hybrid (2)
Internal\DefaultHybridCache.Serialization.cs (1)
18private readonly ConcurrentDictionary<Type, object> _serializers = new();
Internal\DefaultHybridCache.Stampede.cs (1)
13private readonly ConcurrentDictionary<StampedeKey, StampedeState> _currentOperations = new();
Microsoft.Extensions.Caching.Memory (1)
MemoryCache.cs (1)
679internal ConcurrentDictionary<object, CacheEntry> _entries = new ConcurrentDictionary<object, CacheEntry>();
Microsoft.Extensions.DependencyInjection (6)
ServiceLookup\CallSiteFactory.cs (2)
18private readonly ConcurrentDictionary<ServiceCacheKey, ServiceCallSite> _callSiteCache = new ConcurrentDictionary<ServiceCacheKey, ServiceCallSite>(); 20private readonly ConcurrentDictionary<ServiceIdentifier, object> _callSiteLocks = new ConcurrentDictionary<ServiceIdentifier, object>();
ServiceLookup\CallSiteValidator.cs (1)
13private readonly ConcurrentDictionary<ServiceCacheKey, Type?> _scopedServices = new ConcurrentDictionary<ServiceCacheKey, Type?>();
ServiceLookup\Expressions\ExpressionResolverBuilder.cs (1)
52_scopeResolverCache = new ConcurrentDictionary<ServiceCacheKey, Func<ServiceProviderEngineScope, object>>();
ServiceLookup\ILEmit\ILEmitResolverBuilder.cs (1)
62_scopeResolverCache = new ConcurrentDictionary<ServiceCacheKey, GeneratedMethod>();
ServiceProvider.cs (1)
58_serviceAccessors = new ConcurrentDictionary<ServiceIdentifier, ServiceAccessor>();
Microsoft.Extensions.DependencyInjection.Abstractions (1)
ActivatorUtilities.cs (1)
28private static readonly ConcurrentDictionary<Type, ConstructorInfoEx[]> s_constructorInfos = new();
Microsoft.Extensions.Diagnostics.HealthChecks.Common (1)
ManualHealthCheckTracker.cs (1)
15private readonly ConcurrentDictionary<IManualHealthCheck, bool> _checks = new();
Microsoft.Extensions.Diagnostics.Testing (2)
Logging\FakeLogger.cs (1)
22private readonly ConcurrentDictionary<LogLevel, bool> _disabledLevels = new(); // used as a set, the value is ignored
Logging\FakeLoggerProvider.cs (1)
22private readonly ConcurrentDictionary<string, FakeLogger> _loggers = new();
Microsoft.Extensions.FileProviders.Physical (1)
PhysicalFilesWatcher.cs (1)
106PollingChangeTokens = new ConcurrentDictionary<IPollingChangeToken, IPollingChangeToken>();
Microsoft.Extensions.Http.Diagnostics (3)
Latency\Internal\HttpRequestLatencyListener.cs (1)
20private readonly ConcurrentDictionary<string, EventSource?> _eventSources = new()
Logging\Internal\LoggerMessageStateExtensions.cs (2)
14private static readonly ConcurrentDictionary<string, string> _requestPrefixedNamesCache = new(); 15private static readonly ConcurrentDictionary<string, string> _responsePrefixedNamesCache = new();
Microsoft.Extensions.Http.Resilience (1)
Resilience\Internal\ByAuthorityPipelineKeyProvider.cs (1)
12private readonly ConcurrentDictionary<(string scheme, string host, int port), string> _cache = new();
Microsoft.Extensions.Localization (3)
ResourceManagerStringLocalizer.cs (1)
23private readonly ConcurrentDictionary<string, object?> _missingManifestCache = new ConcurrentDictionary<string, object?>();
ResourceManagerStringLocalizerFactory.cs (1)
27new ConcurrentDictionary<string, ResourceManagerStringLocalizer>();
ResourceNamesCache.cs (1)
15private readonly ConcurrentDictionary<string, IList<string>?> _cache = new ConcurrentDictionary<string, IList<string>?>();
Microsoft.Extensions.Logging.Abstractions (1)
FormattedLogValues.cs (1)
22private static readonly ConcurrentDictionary<string, LogValuesFormatter> s_formatters = new ConcurrentDictionary<string, LogValuesFormatter>();
Microsoft.Extensions.Logging.Console (1)
ConsoleLoggerProvider.cs (1)
44_loggers = new ConcurrentDictionary<string, ConsoleLogger>();
Microsoft.Extensions.ML (1)
PredictionEnginePool.cs (1)
42_namedPools = new ConcurrentDictionary<string, PoolLoader<TData, TPrediction>>();
Microsoft.Extensions.ServiceDiscovery (2)
Http\HttpServiceEndpointResolver.cs (1)
21private readonly ConcurrentDictionary<string, ResolverEntry> _resolvers = new();
ServiceEndpointResolver.cs (1)
20private readonly ConcurrentDictionary<string, ResolverEntry> _resolvers = new();
Microsoft.Extensions.Telemetry (1)
Http\HttpRouteParser.cs (1)
24private readonly ConcurrentDictionary<string, ParsedRouteSegments> _routeTemplateSegmentsCache = new();
Microsoft.JSInterop (8)
Infrastructure\DotNetDispatcher.cs (3)
29private static readonly ConcurrentDictionary<AssemblyKey, IReadOnlyDictionary<string, (MethodInfo, Type[])>> _cachedMethodsByAssembly = new(); 31private static readonly ConcurrentDictionary<Type, IReadOnlyDictionary<string, (MethodInfo, Type[])>> _cachedMethodsByType = new(); 33private static readonly ConcurrentDictionary<Type, Func<object, Task>> _cachedConvertToTaskByType = new();
Infrastructure\TaskGenericsUtil.cs (2)
12= new ConcurrentDictionary<Type, ITaskResultGetter>(); 15= new ConcurrentDictionary<Type, ITcsResultSetter>();
JSRuntime.cs (3)
20private readonly ConcurrentDictionary<long, object> _pendingTasks = new(); 21private readonly ConcurrentDictionary<long, IDotNetObjectReference> _trackedRefsById = new(); 22private readonly ConcurrentDictionary<long, CancellationTokenRegistration> _cancellationRegistrations = new();
Microsoft.Maui (9)
Fonts\FontManager.iOS.cs (1)
27 readonly ConcurrentDictionary<Font, UIFont> _fonts = new();
Handlers\HybridWebView\HybridWebViewHandler.cs (1)
424 ConcurrentDictionary<string, TaskCompletionSource<string>> _asyncTaskCallbacks = new ConcurrentDictionary<string, TaskCompletionSource<string>>();
Hosting\ImageSources\ImageSourceServiceProvider.cs (2)
15 readonly ConcurrentDictionary<Type, Type> _imageSourceCache = new ConcurrentDictionary<Type, Type>(); 16 readonly ConcurrentDictionary<Type, Type> _serviceCache = new ConcurrentDictionary<Type, Type>();
Hosting\ImageSources\ImageSourceToImageSourceServiceTypeMapping.cs (1)
10 private static readonly ConcurrentDictionary<IImageSourceServiceCollection, ImageSourceToImageSourceServiceTypeMapping> s_instances = new();
Hosting\Internal\MauiFactory.cs (1)
22 _singletons = new ConcurrentDictionary<ServiceDescriptor, object?>();
Hosting\Internal\MauiHandlersFactory.cs (1)
12 readonly ConcurrentDictionary<Type, Type> _serviceCache = new ConcurrentDictionary<Type, Type>();
Hosting\Internal\RegisteredHandlerServiceTypeSet.cs (1)
10 private static readonly ConcurrentDictionary<IMauiHandlersCollection, RegisteredHandlerServiceTypeSet> s_instances = new();
MauiContext.cs (1)
55 readonly ConcurrentDictionary<Type, (object, Func<object, object?>)> _scopeStatic = new();
Microsoft.Maui.Controls (2)
AnimationExtensions.cs (1)
62 s_tweeners = new ConcurrentDictionary<int, Animation>();
Xaml\TypeConversionExtensions.cs (1)
43 static readonly ConcurrentDictionary<MemberInfo, TypeConverter> s_converterCache = new();
Microsoft.ML.Core (3)
Data\ProgressReporter.cs (1)
59_subChannels = new ConcurrentDictionary<int, SubChannel>();
Data\Repository.cs (1)
113PathMap = new ConcurrentDictionary<string, string>();
Environment\HostEnvironmentBase.cs (1)
377ListenerDict = new ConcurrentDictionary<Type, Dispatcher>();
Microsoft.ML.Core.Tests (2)
UnitTests\TestHosts.cs (2)
31var children = new ConcurrentDictionary<IHost, List<IHost>>(); 94var children = new ConcurrentDictionary<IHost, List<IHost>>();
Microsoft.ML.Data (1)
DataLoadSave\Text\TextLoaderParser.cs (1)
46= new ConcurrentDictionary<DoubleParser.OptionFlags, ValueCreatorCache>();
Microsoft.ML.Ensemble (1)
Selector\SubModelSelector\BaseDiverseSelector.cs (1)
29_predictions = new ConcurrentDictionary<FeatureSubsetModel<TOutput>, TOutput[]>();
Microsoft.ML.FastTree (1)
Utils\BufferPoolManager.cs (1)
30private static readonly ConcurrentDictionary<Type, SortedList<int, List<Array>>> _bufferPools = new ConcurrentDictionary<Type, SortedList<int, List<Array>>>();
Microsoft.ML.IntegrationTests (1)
Debugging.cs (1)
201Lines = new ConcurrentDictionary<string, int>();
Microsoft.ML.InternalCodeAnalyzer (2)
BaseTestClassAnalyzer.cs (1)
55private readonly ConcurrentDictionary<INamedTypeSymbol, bool> _knownTestAttributes = new ConcurrentDictionary<INamedTypeSymbol, bool>();
RelaxTestNamingSuppressor.cs (1)
31var knownTestAttributes = new ConcurrentDictionary<INamedTypeSymbol, bool>();
MSBuild (5)
CachingFileSystemWrapper.cs (2)
16private readonly ConcurrentDictionary<string, bool> _existenceCache = new ConcurrentDictionary<string, bool>(); 17private readonly ConcurrentDictionary<string, DateTime> _lastWriteTimeCache = new ConcurrentDictionary<string, DateTime>();
TypeLoader.cs (3)
34private static ConcurrentDictionary<Func<Type, object, bool>, ConcurrentDictionary<AssemblyLoadInfo, AssemblyInfoToLoadedTypes>> s_cacheOfLoadedTypesByFilter = new ConcurrentDictionary<Func<Type, object, bool>, ConcurrentDictionary<AssemblyLoadInfo, AssemblyInfoToLoadedTypes>>(); 39private static ConcurrentDictionary<Func<Type, object, bool>, ConcurrentDictionary<AssemblyLoadInfo, AssemblyInfoToLoadedTypes>> s_cacheOfReflectionOnlyLoadedTypesByFilter = new ConcurrentDictionary<Func<Type, object, bool>, ConcurrentDictionary<AssemblyLoadInfo, AssemblyInfoToLoadedTypes>>(); 246cache.GetOrAdd(_isDesiredType, (_) => new ConcurrentDictionary<AssemblyLoadInfo, AssemblyInfoToLoadedTypes>());
PresentationFramework (1)
MS\Internal\WindowsRuntime\Generated\WinRT\ComWrappersSupport.cs (1)
19private readonly static ConcurrentDictionary<string, Func<IInspectable, object>> TypedObjectFactoryCache = new ConcurrentDictionary<string, Func<IInspectable, object>>();
System.ComponentModel.Annotations (4)
System\ComponentModel\DataAnnotations\AssociatedMetadataTypeTypeDescriptor.cs (3)
96private static readonly ConcurrentDictionary<Type, Type?> s_metadataTypeCache = new ConcurrentDictionary<Type, Type?>(); 99private static readonly ConcurrentDictionary<(Type, string), Attribute[]> s_typeMemberCache = new ConcurrentDictionary<(Type, string), Attribute[]>(); 102private static readonly ConcurrentDictionary<(Type, Type), bool> s_validatedMetadataTypeCache = new ConcurrentDictionary<(Type, Type), bool>();
System\ComponentModel\DataAnnotations\ValidationAttributeStore.cs (1)
23private readonly ConcurrentDictionary<Type, TypeStoreItem> _typeStoreItems = new();
System.ComponentModel.TypeConverter (3)
System\ComponentModel\ReflectTypeDescriptionProvider.cs (1)
27private readonly ConcurrentDictionary<Type, ReflectedTypeData> _typeData = new ConcurrentDictionary<Type, ReflectedTypeData>();
System\ComponentModel\TypeDescriptor.cs (2)
60private static readonly ConcurrentDictionary<Type, TypeDescriptionNode> s_providerTypeTable = new ConcurrentDictionary<Type, TypeDescriptionNode>(); 65private static readonly ConcurrentDictionary<Type, object?> s_defaultProviderInitialized = new ConcurrentDictionary<Type, object?>();
System.Data.Common (3)
System\Data\Common\DataStorage.cs (1)
128private static readonly ConcurrentDictionary<Type, Tuple<bool, bool, bool, bool>> s_typeImplementsInterface = new ConcurrentDictionary<Type, Tuple<bool, bool, bool, bool>>();
System\Data\Common\DbProviderFactories.cs (1)
36private static readonly ConcurrentDictionary<string, ProviderRegistration> _registeredFactories = new ConcurrentDictionary<string, ProviderRegistration>();
System\Data\Common\SqlUDTStorage.cs (1)
23private static readonly ConcurrentDictionary<Type, object> s_typeToNull = new ConcurrentDictionary<Type, object>();
System.Data.Odbc (3)
src\libraries\Common\src\System\Data\ProviderBase\DbConnectionPoolGroup.cs (3)
58_poolCollection = new ConcurrentDictionary<DbConnectionPoolIdentity, DbConnectionPool>(); 111_poolCollection = new ConcurrentDictionary<DbConnectionPoolIdentity, DbConnectionPool>(); 237var newPoolCollection = new ConcurrentDictionary<DbConnectionPoolIdentity, DbConnectionPool>();
System.Diagnostics.DiagnosticSource (2)
System\Diagnostics\Metrics\AggregationManager.cs (1)
29private readonly ConcurrentDictionary<Instrument, InstrumentState> _instrumentStates = new();
System\Diagnostics\Metrics\AggregatorStore.cs (1)
514GetOrAdd(names, _ => new ConcurrentDictionary<TObjectSequence, TAggregator>());
System.Net.Http (2)
System\Net\Http\SocketsHttpHandler\FailedProxyCache.cs (1)
31private readonly ConcurrentDictionary<Uri, long> _failedProxies = new ConcurrentDictionary<Uri, long>();
System\Net\Http\SocketsHttpHandler\HttpConnectionPoolManager.cs (1)
63_pools = new ConcurrentDictionary<HttpConnectionKey, HttpConnectionPool>();
System.Net.Quic (1)
src\libraries\Common\src\System\Net\SafeHandleCache.cs (1)
38private readonly ConcurrentDictionary<TKey, THandle> _cache = new();
System.Net.Requests (1)
System\Net\ServicePoint\ServicePointManager.cs (1)
18private static readonly ConcurrentDictionary<string, WeakReference<ServicePoint>> s_servicePointTable = new ConcurrentDictionary<string, WeakReference<ServicePoint>>();
System.Net.Security (3)
src\libraries\Common\src\System\Net\SafeHandleCache.cs (1)
38private readonly ConcurrentDictionary<TKey, THandle> _cache = new();
System\Net\Security\SslSessionsCache.cs (1)
18new ConcurrentDictionary<SslCredKey, SafeCredentialReference>();
System\Net\Security\SslStreamCertificateContext.Linux.cs (1)
35Interlocked.CompareExchange(ref _sslContexts, new(), null);
System.Net.Sockets (1)
System\Net\Sockets\SocketAsyncEngine.Unix.cs (1)
83private readonly ConcurrentDictionary<IntPtr, SocketAsyncContextWrapper> _handleToContextMap = new ConcurrentDictionary<IntPtr, SocketAsyncContextWrapper>();
System.Private.DataContractSerialization (3)
System\Runtime\Serialization\ContextAware.cs (1)
54private readonly ConcurrentDictionary<TKey, TValue> _fastDictionary = new();
System\Runtime\Serialization\DataContract.cs (1)
301private static readonly ConcurrentDictionary<nint, int> s_typeToIDCache = new();
System\Runtime\Serialization\Json\JsonDataContract.cs (1)
155private static readonly ConcurrentDictionary<nint, int> s_typeToIDCache = new();
System.Private.Windows.Core (1)
System\Private\Windows\Core\BinaryFormat\SerializationEvents.cs (1)
12private static readonly ConcurrentDictionary<Type, SerializationEvents> s_cache = new();
System.Private.Windows.Core.TestUtilities (1)
NoAssertContext.cs (1)
26private static readonly ConcurrentDictionary<int, int> s_suppressedThreads = new();
System.Reflection.MetadataLoadContext (8)
System\CoreRtBridge.cs (1)
52private readonly ConcurrentDictionary<K, V> _dict = new ConcurrentDictionary<K, V>();
System\Reflection\MetadataLoadContext.Loading.cs (1)
18private readonly ConcurrentDictionary<RoAssemblyName, RoAssembly> _loadedAssemblies = new ConcurrentDictionary<RoAssemblyName, RoAssembly>();
System\Reflection\MetadataLoadContext.Resolving.cs (1)
23private readonly ConcurrentDictionary<RoAssemblyName, RoAssembly> _binds = new ConcurrentDictionary<RoAssemblyName, RoAssembly>();
System\Reflection\TypeLoading\Modules\RoModule.Unifier.cs (5)
21private readonly ConcurrentDictionary<RoType, RoArrayType> _szArrayDict = new ConcurrentDictionary<RoType, RoArrayType>(); 35private readonly ConcurrentDictionary<RoArrayType.Key, RoArrayType> _mdArrayDict = new ConcurrentDictionary<RoArrayType.Key, RoArrayType>(); 48private readonly ConcurrentDictionary<RoType, RoByRefType> _byRefDict = new ConcurrentDictionary<RoType, RoByRefType>(); 59private readonly ConcurrentDictionary<RoType, RoPointerType> _pointerDict = new ConcurrentDictionary<RoType, RoPointerType>(); 70private readonly ConcurrentDictionary<RoConstructedGenericType.Key, RoConstructedGenericType> _constructedGenericTypeDict = new ConcurrentDictionary<RoConstructedGenericType.Key, RoConstructedGenericType>();
System.Resources.Extensions (1)
System\Resources\Extensions\BinaryFormat\SerializationEvents.cs (1)
14private static readonly ConcurrentDictionary<Type, SerializationEvents> s_cache = new();
System.Runtime.Serialization.Formatters (2)
System\Runtime\Serialization\FormatterServices.cs (1)
18private static readonly ConcurrentDictionary<MemberHolder, MemberInfo[]> s_memberInfoTable = new ConcurrentDictionary<MemberHolder, MemberInfo[]>();
System\Runtime\Serialization\SerializationEventsCache.cs (1)
98private static readonly ConcurrentDictionary<Type, SerializationEvents> s_cache = new ConcurrentDictionary<Type, SerializationEvents>();
System.Security.Cryptography (3)
src\libraries\Common\src\Interop\Unix\System.Security.Cryptography.Native\Interop.ASN1.Nid.cs (1)
14new ConcurrentDictionary<string, int>();
System\Security\Cryptography\OidLookup.cs (1)
13new ConcurrentDictionary<string, string>();
System\Security\Cryptography\X509Certificates\OpenSslX509ChainProcessor.cs (1)
41new ConcurrentDictionary<int, string>();
System.Text.Json (4)
System\Text\Json\Serialization\Converters\Value\EnumConverter.cs (1)
65_nameCacheForWriting = new();
System\Text\Json\Serialization\JsonSerializerOptions.Caching.cs (1)
215private readonly ConcurrentDictionary<Type, CacheEntry> _cache = new();
System\Text\Json\Serialization\Metadata\PolymorphicTypeResolver.cs (1)
18private readonly ConcurrentDictionary<Type, DerivedJsonTypeInfo?> _typeToDiscriminatorId = new();
System\Text\Json\Serialization\Metadata\ReflectionEmitCachingMemberAccessor.Cache.cs (1)
20private readonly ConcurrentDictionary<TKey, CacheEntry> _cache = new();
System.Windows.Forms (2)
System\Resources\AssemblyNamesTypeResolutionService.cs (1)
26_cachedAssemblies ??= new();
System\Windows\Forms\Controls\ToolStrips\ToolStripManager.cs (1)
25private static readonly ConcurrentDictionary<int, Font> s_defaultFontCache = new();
Templates.Blazor.Tests (1)
src\ProjectTemplates\Shared\ProjectFactoryFixture.cs (1)
18private readonly ConcurrentDictionary<string, Project> _projects = new ConcurrentDictionary<string, Project>();
Templates.Blazor.WebAssembly.Auth.Tests (2)
src\ProjectTemplates\Shared\ProjectFactoryFixture.cs (1)
18private readonly ConcurrentDictionary<string, Project> _projects = new ConcurrentDictionary<string, Project>();
src\Shared\E2ETesting\BrowserFixture.cs (1)
19private readonly ConcurrentDictionary<string, (IWebDriver browser, ILogs log)> _browsers = new();
Templates.Blazor.WebAssembly.Tests (2)
src\ProjectTemplates\Shared\ProjectFactoryFixture.cs (1)
18private readonly ConcurrentDictionary<string, Project> _projects = new ConcurrentDictionary<string, Project>();
src\Shared\E2ETesting\BrowserFixture.cs (1)
19private readonly ConcurrentDictionary<string, (IWebDriver browser, ILogs log)> _browsers = new();
Templates.Mvc.Tests (2)
src\ProjectTemplates\Shared\ProjectFactoryFixture.cs (1)
18private readonly ConcurrentDictionary<string, Project> _projects = new ConcurrentDictionary<string, Project>();
src\Shared\E2ETesting\BrowserFixture.cs (1)
19private readonly ConcurrentDictionary<string, (IWebDriver browser, ILogs log)> _browsers = new();
Templates.Tests (2)
src\ProjectTemplates\Shared\ProjectFactoryFixture.cs (1)
18private readonly ConcurrentDictionary<string, Project> _projects = new ConcurrentDictionary<string, Project>();
src\Shared\E2ETesting\BrowserFixture.cs (1)
19private readonly ConcurrentDictionary<string, (IWebDriver browser, ILogs log)> _browsers = new();
TestContentPackage (1)
Services\AsyncOperationService.cs (1)
10private readonly ConcurrentDictionary<string, TaskCompletionSource> _tasks = new();
XmlFileLogger (1)
ObjectModel\Build.cs (1)
21private readonly ConcurrentDictionary<int, Project> _projectIdToProjectMap = new ConcurrentDictionary<int, Project>();
xunit.assert (4)
Sdk\AssertEqualityComparer.cs (2)
140 static readonly ConcurrentDictionary<Type, TypeInfo> cacheOfIComparableOfT = new ConcurrentDictionary<Type, TypeInfo>(); 141 static readonly ConcurrentDictionary<Type, TypeInfo> cacheOfIEquatableOfT = new ConcurrentDictionary<Type, TypeInfo>();
Sdk\AssertHelper.cs (1)
63 static readonly ConcurrentDictionary<Type, Dictionary<string, Func<object?, object?>>> gettersByType = new ConcurrentDictionary<Type, Dictionary<string, Func<object?, object?>>>();
Sdk\CollectionTrackerExtensions.cs (1)
46 static readonly ConcurrentDictionary<Type, MethodInfo> cacheOfAsTrackerByType = new ConcurrentDictionary<Type, MethodInfo>();
xunit.console (1)
ConsoleRunner.cs (1)
22readonly ConcurrentDictionary<string, ExecutionSummary> completionMessages = new ConcurrentDictionary<string, ExecutionSummary>();