3655 references to ConfigureAwait
AnalyzerRunner (6)
aspire (13)
Aspire.Cli.Tests (2)
Aspire.Dashboard (121)
Model\Assistant\AssistantChatDataContext.cs (11)
51await callback(toolName, message, cancellationToken).ConfigureAwait(false);
65await InvokeToolCallbackAsync(nameof(GetResourceGraphAsync), _loc[nameof(AIAssistant.ToolNotificationResourceGraph)], cancellationToken).ConfigureAwait(false);
92await InvokeToolCallbackAsync(nameof(GetTraceAsync), _loc.GetString(nameof(AIAssistant.ToolNotificationTraceFailure), OtlpHelpers.ToShortenedId(traceId)), cancellationToken).ConfigureAwait(false);
96await InvokeToolCallbackAsync(nameof(GetTraceAsync), _loc.GetString(nameof(AIAssistant.ToolNotificationTrace), OtlpHelpers.ToShortenedId(traceId)), cancellationToken).ConfigureAwait(false);
113await InvokeToolCallbackAsync(nameof(GetStructuredLogsAsync), _loc.GetString(nameof(AIAssistant.ToolNotificationStructuredLogsResourceFailure), resourceName), cancellationToken).ConfigureAwait(false);
120await InvokeToolCallbackAsync(nameof(GetStructuredLogsAsync), toolMessage, cancellationToken).ConfigureAwait(false);
156await InvokeToolCallbackAsync(nameof(GetTracesAsync), _loc.GetString(nameof(AIAssistant.ToolNotificationTracesResourceFailure), resourceName), cancellationToken).ConfigureAwait(false);
163await InvokeToolCallbackAsync(nameof(GetTracesAsync), toolMessage, cancellationToken).ConfigureAwait(false);
209await InvokeToolCallbackAsync(nameof(GetTraceStructuredLogsAsync), _loc.GetString(nameof(AIAssistant.ToolNotificationTraceStructuredLogs), OtlpHelpers.ToShortenedId(traceId)), cancellationToken).ConfigureAwait(false);
238await InvokeToolCallbackAsync(nameof(GetConsoleLogsAsync), _loc.GetString(nameof(AIAssistant.ToolNotificationConsoleLogsFailure), resourceName), cancellationToken).ConfigureAwait(false);
242await InvokeToolCallbackAsync(nameof(GetConsoleLogsAsync), _loc.GetString(nameof(AIAssistant.ToolNotificationConsoleLogs), resourceName), cancellationToken).ConfigureAwait(false);
Model\Assistant\AssistantChatViewModel.cs (29)
262await callback(toolName, message, cancellationToken).ConfigureAwait(false);
276await callback(chatViewModel, responseState, cancellationToken).ConfigureAwait(false);
286await callback(_cts.Token).ConfigureAwait(false);
297await InvokeInitializedCallbackAsync().ConfigureAwait(false);
309await InvokeInitializedCallbackAsync().ConfigureAwait(false);
316await addInitialPrompt().ConfigureAwait(false);
321await InvokeInitializedCallbackAsync().ConfigureAwait(false);
323await CallServiceAsync().ConfigureAwait(false);
327await InvokeInitializedCallbackAsync().ConfigureAwait(false);
423await callback(_cts.Token).ConfigureAwait(false);
493await _currentCallTask.ConfigureAwait(false);
524await InvokeConversationChangedCallbackAsync(_currentAssistantResponse, _responseState, cancellationToken).ConfigureAwait(false);
542await InvokeConversationChangedCallbackAsync(_currentAssistantResponse, _responseState, cancellationToken).ConfigureAwait(false);
551responseCts).ConfigureAwait(false);
581await conversationChangedTask.ConfigureAwait(false);
703await updateFollowUpPromptsTask.ConfigureAwait(false);
704await InvokeConversationChangedCallbackAsync(callAssistantResponse, _responseState, cancellationToken).ConfigureAwait(false);
755await conversationChangedTask.ConfigureAwait(false);
761responseCts).ConfigureAwait(false);
777await conversationChangedTask.ConfigureAwait(false);
855await InvokeConversationChangedCallbackAsync(vm, ResponseState.Starting, _cts.Token).ConfigureAwait(false);
867await InvokeConversationChangedCallbackAsync(chatViewModel, ResponseState.Starting, _cts.Token).ConfigureAwait(false);
897await disconnectCallback().ConfigureAwait(false);
912new AssistantChatAssistantSettings(SelectedModel?.Family)).ConfigureAwait(false);
944await InvokeConversationChangedCallbackAsync(currentChatViewModel, ResponseState.Starting, _cts.Token).ConfigureAwait(false);
952await item.CreatePrompt(new InitializePromptContext(chatBuilder, _dataContext, _serviceProvider, _dashboardOptions.CurrentValue)).ConfigureAwait(false);
954await AddFollowUpPromptAsync(chatBuilder.Build()).ConfigureAwait(false);
956await CallServiceAsync().ConfigureAwait(false);
968await CallServiceAsync().ConfigureAwait(false);
Aspire.Dashboard.Components.Tests (2)
Aspire.Dashboard.Tests (2)
Aspire.EndToEnd.Tests (5)
Aspire.Hosting (295)
Dcp\DcpExecutor.cs (45)
163await _executorEvents.PublishAsync(new OnResourcesPreparedContext(cancellationToken)).ConfigureAwait(false);
170).WaitAsync(cancellationToken).ConfigureAwait(false);
174await UpdateWithEffectiveAddressInfo(proxiedWithNoAddress, cancellationToken).ConfigureAwait(false);
176await CreateAllDcpObjectsAsync<ContainerNetworkTunnelProxy>(cancellationToken).ConfigureAwait(false);
177await EnsureContainerServiceAddressInfo(cancellationToken).ConfigureAwait(false);
184await _executorEvents.PublishAsync(new OnEndpointsAllocatedContext(cancellationToken)).ConfigureAwait(false);
198).ConfigureAwait(false);
206).WaitAsync(cancellationToken).ConfigureAwait(false);
246await Task.WhenAll(tasks).WaitAsync(cancellationToken).ConfigureAwait(false);
261await _kubernetesService.CleanupResourcesAsync(cancellationToken).ConfigureAwait(false);
270await _kubernetesService.StopServerAsync(Model.ResourceCleanup.Full, cancellationToken).ConfigureAwait(false);
286await StopAsync(disposeCts.Token).ConfigureAwait(false);
303Task.Run(() => WatchKubernetesResourceAsync<Endpoint>(ProcessEndpointChange))).ConfigureAwait(false);
381await outputSemaphore.WaitAsync(pipelineCancellationToken).ConfigureAwait(false);
385await handler(eventType, resource).ConfigureAwait(false);
452await _executorEvents.PublishAsync(new OnResourceChangedContext(_shutdownCancellation.Token, resourceType, appModelResource, resource.Metadata.Name, status, s => snapshotFactory(resource, s))).ConfigureAwait(false);
737})).ConfigureAwait(false);
847await UpdateWithEffectiveAddressInfo(tunnelServices, cancellationToken, TimeSpan.FromMinutes(10)).ConfigureAwait(false);
891await Task.WhenAll(tasks).WaitAsync(cancellationToken).ConfigureAwait(false);
1424await Task.WhenAll(tasks).WaitAsync(cancellationToken).ConfigureAwait(false);
1453).ConfigureAwait(false);
1456await _executorEvents.PublishAsync(new OnResourceStartingContext(cancellationToken, resourceType, resource, DcpResourceName: null)).ConfigureAwait(false);
1462await _executorEvents.PublishAsync(new OnResourceChangedContext(cancellationToken, resourceType, resource, er.DcpResource.Metadata.Name, new ResourceStatus(KnownResourceStates.NotStarted, null, null), s => s with { State = new ResourceStateSnapshot(KnownResourceStates.NotStarted, null) })).ConfigureAwait(false);
1468await createResourceFunc(er, resourceLogger, cancellationToken).ConfigureAwait(false);
1475await _executorEvents.PublishAsync(new OnResourceFailedToStartContext(cancellationToken, resourceType, er.ModelResource, er.DcpResource.Metadata.Name)).ConfigureAwait(false);
1483await _executorEvents.PublishAsync(new OnResourceFailedToStartContext(cancellationToken, resourceType, er.ModelResource, er.DcpResource.Metadata.Name)).ConfigureAwait(false);
1494await _executorEvents.PublishAsync(new OnResourceFailedToStartContext(cancellationToken, resourceType, resource, DcpResourceName: null)).ConfigureAwait(false);
1718await CreateContainerAsync(cr, logger, cancellationToken).ConfigureAwait(false);
1725await _executorEvents.PublishAsync(new OnResourceFailedToStartContext(cancellationToken, KnownResourceTypes.Container, cr.ModelResource, cr.DcpResourceName)).ConfigureAwait(false);
1730await _executorEvents.PublishAsync(new OnResourceFailedToStartContext(cancellationToken, KnownResourceTypes.Container, cr.ModelResource, cr.DcpResourceName)).ConfigureAwait(false);
1740await _executorEvents.PublishAsync(new OnResourceChangedContext(_shutdownCancellation.Token, KnownResourceTypes.Container, cr.ModelResource, cr.DcpResourceName, new ResourceStatus(null, null, null), s => _snapshotBuilder.ToSnapshot((Container)cr.DcpResource, s))).ConfigureAwait(false);
1754await Task.WhenAll(tasks).WaitAsync(cancellationToken).ConfigureAwait(false);
1764await _executorEvents.PublishAsync(new OnResourceStartingContext(cancellationToken, KnownResourceTypes.Container, cr.ModelResource, cr.DcpResource.Metadata.Name)).ConfigureAwait(false);
1769await ApplyBuildArgumentsAsync(dcpContainerResource, modelContainerResource, _executionContext.ServiceProvider, cancellationToken).ConfigureAwait(false);
1840await DockerfileHelper.ExecuteDockerfileFactoryAsync(dockerfileBuildAnnotation, modelContainerResource, serviceProvider, cancellationToken).ConfigureAwait(false);
2112await EnsureResourceDeletedAsync<Container>(appResource.DcpResourceName).ConfigureAwait(false);
2117await _executorEvents.PublishAsync(new OnResourceStartingContext(cancellationToken, resourceType, appResource.ModelResource, appResource.DcpResourceName)).ConfigureAwait(false);
2118await CreateContainerAsync(appResource, resourceLogger, cancellationToken).ConfigureAwait(false);
2121await EnsureResourceDeletedAsync<Executable>(appResource.DcpResourceName).ConfigureAwait(false);
2123await _executorEvents.PublishAsync(new OnResourceStartingContext(cancellationToken, resourceType, appResource.ModelResource, appResource.DcpResourceName)).ConfigureAwait(false);
2124await CreateExecutableAsync(appResource, resourceLogger, cancellationToken).ConfigureAwait(false);
2136await _executorEvents.PublishAsync(new OnResourceFailedToStartContext(cancellationToken, resourceType, appResource.ModelResource, appResource.DcpResourceName)).ConfigureAwait(false);
2141await _executorEvents.PublishAsync(new OnResourceFailedToStartContext(cancellationToken, resourceType, appResource.ModelResource, appResource.DcpResourceName)).ConfigureAwait(false);
2580await callback.Callback(context).ConfigureAwait(false);
2716await callback.Callback(context).ConfigureAwait(false);
Orchestrator\ApplicationOrchestrator.cs (36)
85.ConfigureAwait(false);
113await completedTask.ConfigureAwait(false);
128await _eventing.PublishAsync(afterEndpointsAllocatedEvent, context.CancellationToken).ConfigureAwait(false);
132await lifecycleHook.AfterEndpointsAllocatedAsync(_model, context.CancellationToken).ConfigureAwait(false);
139await ProcessResourceUrlCallbacks(resource, cancellationToken).ConfigureAwait(false);
143await _notificationService.PublishUpdateAsync(resource, s => s with { Urls = [.. urls] }).ConfigureAwait(false);
174.ConfigureAwait(false);
185.ConfigureAwait(false);
188await SetChildResourceAsync(context.Resource, state: KnownResourceStates.Starting, startTimeStamp: null, stopTimeStamp: null).ConfigureAwait(false);
194await PublishConnectionStringAvailableEvent(context.Resource, context.CancellationToken).ConfigureAwait(false);
197await _eventing.PublishAsync(beforeResourceStartedEvent, context.CancellationToken).ConfigureAwait(false);
209await PublishResourcesInitialStateAsync(context.CancellationToken).ConfigureAwait(false);
344await callback.Callback(urlsCallbackContext).ConfigureAwait(false);
397await PublishResourceEndpointUrls(@event.Resource, cancellationToken).ConfigureAwait(false);
409await _notificationService.PublishUpdateAsync(context.Resource, context.DcpResourceName, context.UpdateSnapshot).ConfigureAwait(false);
413await SetChildResourceAsync(context.Resource, context.Status.State, context.Status.StartupTimestamp, context.Status.FinishedTimestamp).ConfigureAwait(false);
428await PublishEventToHierarchy(r => new ResourceStoppedEvent(r, _serviceProvider, currentResourceEvent), context.Resource, context.CancellationToken).ConfigureAwait(false);
437await _notificationService.PublishUpdateAsync(context.Resource, context.DcpResourceName, s => s with { State = KnownResourceStates.FailedToStart }).ConfigureAwait(false);
441await SetChildResourceAsync(context.Resource, KnownResourceStates.FailedToStart, startTimeStamp: null, stopTimeStamp: null).ConfigureAwait(false);
446await _notificationService.PublishUpdateAsync(context.Resource, s => s with { State = KnownResourceStates.FailedToStart }).ConfigureAwait(false);
452await _dcpExecutor.RunApplicationAsync(cancellationToken).ConfigureAwait(false);
455await _eventing.PublishAsync(afterResourcesCreatedEvent, cancellationToken).ConfigureAwait(false);
459await lifecycleHook.AfterResourcesCreatedAsync(_model, cancellationToken).ConfigureAwait(false);
467await _dcpExecutor.StopAsync(cancellationToken).ConfigureAwait(false);
489}).ConfigureAwait(false);
495await _dcpExecutor.StartResourceAsync(resourceReference, cancellationToken).ConfigureAwait(false);
502await _dcpExecutor.StopResourceAsync(resourceReference, cancellationToken).ConfigureAwait(false);
520}).ConfigureAwait(false);
524.ConfigureAwait(false);
531await _parameterProcessor.InitializeParametersAsync(_model.Resources.OfType<ParameterResource>(), waitForResolution: false).ConfigureAwait(false);
552}).ConfigureAwait(false);
556await _eventing.PublishAsync(initializeEvent, EventDispatchBehavior.NonBlockingConcurrent, cancellationToken).ConfigureAwait(false);
577await _eventing.PublishAsync(connectionStringAvailableEvent, cancellationToken).ConfigureAwait(false);
592await PublishConnectionStringAvailableEvent(child, cancellationToken).ConfigureAwait(false);
601await _eventing.PublishAsync(createEvent(resource), cancellationToken).ConfigureAwait(false);
613await PublishEventToHierarchy(createEvent, child, cancellationToken).ConfigureAwait(false);
Orchestrator\ParameterProcessor.cs (13)
45await ProcessParameterAsync(parameterResource).ConfigureAwait(false);
57await HandleUnresolvedParametersAsync().ConfigureAwait(false);
68await parameterResolutionTask.ConfigureAwait(false);
86await CollectDependentParameterResourcesAsync(model, referencedParameters, currentDependencySet, cancellationToken).ConfigureAwait(false);
95await InitializeParametersAsync(allParameters, waitForResolution).ConfigureAwait(false);
101await SaveParametersToDeploymentStateAsync(allParameters, cancellationToken).ConfigureAwait(false);
114await ProcessResourceDependenciesAsync(resource, executionContext, referencedParameters, currentDependencySet, cancellationToken).ConfigureAwait(false);
182.ConfigureAwait(false);
219.ConfigureAwait(false);
226await HandleUnresolvedParametersAsync(_unresolvedParameters).ConfigureAwait(false);
340.ConfigureAwait(false);
367await deploymentStateManager.SaveSectionAsync(parametersStateSection).ConfigureAwait(false);
395await deploymentStateManager.SaveSectionAsync(parametersSection, cancellationToken).ConfigureAwait(false);
Publishing\ManifestPublishingContext.cs (23)
93await WriteResourceAsync(resource).ConfigureAwait(false);
96await WriteReferencedResources(model).ConfigureAwait(false);
103await Writer.FlushAsync(cancellationToken).ConfigureAwait(false);
117await WriteResourceObjectAsync(resource, () => manifestPublishingCallbackAnnotation.Callback(this)).ConfigureAwait(false);
122await WriteResourceObjectAsync(container, () => WriteContainerAsync(container)).ConfigureAwait(false);
126await WriteResourceObjectAsync(project, () => WriteProjectAsync(project)).ConfigureAwait(false);
130await WriteResourceObjectAsync(executable, () => WriteExecutableAsync(executable)).ConfigureAwait(false);
134await WriteResourceObjectAsync(parameter, () => WriteParameterAsync(parameter)).ConfigureAwait(false);
138await WriteResourceObjectAsync(resource, () => WriteConnectionStringAsync(resourceWithConnectionString)).ConfigureAwait(false);
142await WriteResourceObjectAsync(resource, WriteErrorAsync).ConfigureAwait(false);
148await action().ConfigureAwait(false);
196await WriteDeploymentTarget(deploymentTarget).ConfigureAwait(false);
201await WriteCommandLineArgumentsAsync(project).ConfigureAwait(false);
203await WriteEnvironmentVariablesAsync(project).ConfigureAwait(false);
214await manifestPublishingCallbackAnnotation.Callback(this).ConfigureAwait(false);
267await WriteCommandLineArgumentsAsync(executable).ConfigureAwait(false);
269await WriteEnvironmentVariablesAsync(executable).ConfigureAwait(false);
321await WriteBuildContextAsync(container).ConfigureAwait(false);
345await WriteDeploymentTarget(deploymentTarget).ConfigureAwait(false);
354await WriteCommandLineArgumentsAsync(container).ConfigureAwait(false);
362await WriteEnvironmentVariablesAsync(container).ConfigureAwait(false);
373await DockerfileHelper.ExecuteDockerfileFactoryAsync(annotation, container, ExecutionContext.ServiceProvider, CancellationToken).ConfigureAwait(false);
937await WriteResourceAsync(resource).ConfigureAwait(false);
Publishing\PublishingExtensions.cs (7)
29await step.CompleteAsync(completionText, CompletionState.Completed, cancellationToken).ConfigureAwait(false);
46await step.CompleteAsync(completionText, CompletionState.CompletedWithWarning, cancellationToken).ConfigureAwait(false);
63await step.CompleteAsync(completionText, CompletionState.CompletedWithError, cancellationToken).ConfigureAwait(false);
79await task.UpdateAsync(statusText, cancellationToken).ConfigureAwait(false);
95await task.CompleteAsync(message, CompletionState.Completed, cancellationToken).ConfigureAwait(false);
111await task.CompleteAsync(message, CompletionState.CompletedWithWarning, cancellationToken).ConfigureAwait(false);
127await task.CompleteAsync(errorMessage, CompletionState.CompletedWithError, cancellationToken).ConfigureAwait(false);
Aspire.Hosting.Azure (70)
AzureEnvironmentResourceHelpers.cs (7)
55context.CancellationToken).ConfigureAwait(false);
57await loginTask.CompleteAsync($"Successfully logged in to **{registryEndpoint}**", CompletionState.Completed, context.CancellationToken).ConfigureAwait(false);
89await TagAndPushImage(localImageName, targetTag, context.CancellationToken, containerImageBuilder).ConfigureAwait(false);
90await pushTask.CompleteAsync($"Successfully pushed **{resource.Name}** to `{targetTag}`", CompletionState.Completed, context.CancellationToken).ConfigureAwait(false);
94await pushTask.CompleteAsync($"Failed to push **{resource.Name}**: {ex.Message}", CompletionState.CompletedWithError, context.CancellationToken).ConfigureAwait(false);
102await containerImageBuilder.TagImageAsync(localTag, targetTag, cancellationToken).ConfigureAwait(false);
103await containerImageBuilder.PushImageAsync(targetTag, cancellationToken).ConfigureAwait(false);
AzurePublishingContext.cs (13)
97await WriteAzureArtifactsOutputAsync(ReportingStep, model, environment, cancellationToken).ConfigureAwait(false);
99await SaveToDiskAsync(outputPath).ConfigureAwait(false);
125await MapParameterAsync(environment.ResourceGroupName, cancellationToken).ConfigureAwait(false);
126await MapParameterAsync(environment.Location, cancellationToken).ConfigureAwait(false);
127await MapParameterAsync(environment.PrincipalId, cancellationToken).ConfigureAwait(false);
171await VisitAsync(existingAnnotation.ResourceGroup, MapParameterAsync, cancellationToken).ConfigureAwait(false);
172await VisitAsync(existingAnnotation.Name, MapParameterAsync, cancellationToken).ConfigureAwait(false);
178await VisitAsync(parameter.Value, MapParameterAsync, cancellationToken).ConfigureAwait(false);
282await computeEnvironmentTask.CompleteAsync(message, state, cancellationToken).ConfigureAwait(false);
321await File.WriteAllTextAsync(dockerfileBuildAnnotation.DockerfilePath, dockerfileContent, cancellationToken).ConfigureAwait(false);
449await visitor(value, cancellationToken).ConfigureAwait(false);
455await VisitAsync(reference, visitor, visited, cancellationToken).ConfigureAwait(false);
473await File.WriteAllTextAsync(bicepPath, compiledBicep.Value).ConfigureAwait(false);
Aspire.Hosting.Azure.AIFoundry (12)
Aspire.Hosting.Azure.AppContainers (7)
Aspire.Hosting.Azure.AppService (7)
Aspire.Hosting.Azure.Kusto (2)
Aspire.Hosting.Azure.Kusto.Tests (2)
Aspire.Hosting.DevTunnels (22)
DevTunnelResourceBuilderExtensions.cs (12)
125await devTunnelCliInstallationManager.EnsureInstalledAsync(ct).ConfigureAwait(false);
129await devTunnelEnvironmentManager.EnsureUserLoggedInAsync(ct).ConfigureAwait(false);
157await Task.WhenAll(portTasks).ConfigureAwait(false);
180}).ConfigureAwait(false);
202await eventing.PublishAsync<BeforeResourceStartedEvent>(new(portResource, e.Services), EventDispatchBehavior.NonBlockingConcurrent, ct).ConfigureAwait(false);
610await eventing.PublishAsync<BeforeResourceStartedEvent>(new(portResource, services), EventDispatchBehavior.NonBlockingSequential, ct).ConfigureAwait(false);
615}).ConfigureAwait(false);
624await eventing.PublishAsync<ResourceEndpointsAllocatedEvent>(new(portResource, services), ct).ConfigureAwait(false);
643}).ConfigureAwait(false);
661}).ConfigureAwait(false);
689}).ConfigureAwait(false);
690await eventing.PublishAsync<ResourceStoppedEvent>(new(portResource, e.Services, new(portResource, portResource.Name, stoppedSnapshot!)), ct).ConfigureAwait(false);
Aspire.Hosting.DevTunnels.Tests (2)
Aspire.Hosting.Docker (12)
Aspire.Hosting.GitHub.Models (2)
Aspire.Hosting.GitHub.Models.Tests (2)
Aspire.Hosting.JavaScript.Tests (2)
Aspire.Hosting.Kafka.Tests (2)
Aspire.Hosting.Kubernetes (18)
KubernetesPublishingContext.cs (13)
62await WriteKubernetesOutputAsync(model, environment).ConfigureAwait(false);
86await File.WriteAllTextAsync(dockerfileBuildAnnotation.DockerfilePath, dockerfileContent, cancellationToken).ConfigureAwait(false);
102await WriteKubernetesTemplatesForResource(resource, serviceResource.GetTemplatedResources()).ConfigureAwait(false);
103await AppendResourceContextToHelmValuesAsync(resource, serviceResource).ConfigureAwait(false);
107await WriteKubernetesHelmChartAsync(environment).ConfigureAwait(false);
108await WriteKubernetesHelmValuesAsync().ConfigureAwait(false);
113await AddValuesToHelmSectionAsync(resource, resourceContext.Parameters, HelmExtensions.ParametersKey).ConfigureAwait(false);
114await AddValuesToHelmSectionAsync(resource, resourceContext.EnvironmentVariables, HelmExtensions.ConfigKey).ConfigureAwait(false);
115await AddValuesToHelmSectionAsync(resource, resourceContext.Secrets, HelmExtensions.SecretsKey).ConfigureAwait(false);
170await writer.WriteLineAsync(HelmExtensions.TemplateFileSeparator).ConfigureAwait(false);
171await writer.WriteAsync(yaml).ConfigureAwait(false);
196await File.WriteAllTextAsync(outputFile, valuesYaml, cancellationToken).ConfigureAwait(false);
216await File.WriteAllTextAsync(outputFile, chartYaml, cancellationToken).ConfigureAwait(false);
Aspire.Hosting.Maui (6)
Aspire.Hosting.MySql (2)
Aspire.Hosting.MySql.Tests (2)
Aspire.Hosting.OpenAI (4)
Aspire.Hosting.OpenAI.Tests (2)
Aspire.Hosting.PostgreSQL (2)
Aspire.Hosting.PostgreSQL.Tests (2)
Aspire.Hosting.Python (7)
Aspire.Hosting.RabbitMQ.Tests (2)
Aspire.Hosting.SqlServer (2)
Aspire.Hosting.Testing (12)
Aspire.Hosting.Testing.Tests (1)
Aspire.Hosting.Tests (6)
Aspire.Hosting.Valkey.Tests (2)
Aspire.Playground.Tests (3)
Aspire.Templates.Tests (5)
Binding.Tcp.IntegrationTests (1)
csc (11)
src\Compilers\Shared\BuildProtocol.cs (7)
128await ReadAllAsync(inStream, lengthBuffer, 4, cancellationToken).ConfigureAwait(false);
187cancellationToken).ConfigureAwait(false);
190await memoryStream.CopyToAsync(outStream, bufferSize: length, cancellationToken: cancellationToken).ConfigureAwait(false);
305cancellationToken).ConfigureAwait(false);
308await memoryStream.CopyToAsync(outStream, bufferSize: length, cancellationToken: cancellationToken).ConfigureAwait(false);
324await ReadAllAsync(stream, lengthBuffer, 4, cancellationToken).ConfigureAwait(false);
332cancellationToken).ConfigureAwait(false);
dotnet-svcutil-lib (132)
CommandProcessorOptions.cs (22)
208await ProcessProjectFileOptionAsync(cancellationToken).ConfigureAwait(false);
211await ProcessUpdateOptionAsync(cancellationToken).ConfigureAwait(false);
214await ProcessOutputDirOptionAsync(this.Project?.DirectoryPath, cancellationToken).ConfigureAwait(false);
219await ProcessBootstrapDirOptionAsync(cancellationToken).ConfigureAwait(false);
222await ProcessNamespaceMappingsOptionAsync(cancellationToken).ConfigureAwait(false);
225await ProcessInputsAsync(cancellationToken).ConfigureAwait(false);
228await ProcessTargetFrameworkOptionAsync(cancellationToken).ConfigureAwait(false);
233await ProcessReferencesOptionAsync(cancellationToken).ConfigureAwait(false);
238await ProcessReferenceAssembliesAsync(cancellationToken).ConfigureAwait(false);
291await safeLogger.WriteMessageAsync($"Tool context: {this.ToolContext}", logToUI: false).ConfigureAwait(false);
308await safeLogger.WriteMessageAsync($"Resetting unexpected option '{InputsKey}' ...", logToUI: false).ConfigureAwait(false);
315await safeLogger.WriteMessageAsync($"Resetting unexpected option '{option.Name}' ...", logToUI: false).ConfigureAwait(false);
365await logger.WriteMessageAsync($"{ProjectFileKey}:\"{projectFile}\"", logToUI: false).ConfigureAwait(false);
387await ProcessOutputFileOptionAsync(defaultDir, cancellationToken).ConfigureAwait(false);
401await logger.WriteMessageAsync($"{OutputDirKey}:\"{this.OutputDir}\"", logToUI: false).ConfigureAwait(false);
459await logger.WriteMessageAsync($"{OutputFileKey}:\"{filePath}\"", logToUI: false).ConfigureAwait(false);
560await logger.WriteMessageAsync($"Update option read from \"{paramsFilePath}\" ...", logToUI: false).ConfigureAwait(false);
583await logger.WriteMessageAsync($"{BootstrapPathKey}:\"{this.BootstrapPath}\"", logToUI: false).ConfigureAwait(false);
619await logger.WriteMessageAsync(Shared.Resources.ResolvingProjectReferences, logToUI: this.ToolContext <= OperationalContext.Global).ConfigureAwait(false);
707await SetupBootstrappingDirectoryAsync(logger, cancellationToken).ConfigureAwait(false);
737await safeLogger.WriteMessageAsync($"resolved inputs: {inputFiles.Count()}", logToUI: false).ConfigureAwait(false);
1014await RuntimeEnvironmentHelper.TryCopyingConfigFiles(workingDirectory, this.BootstrapPath.FullName, logger, cancellationToken).ConfigureAwait(false);
FrameworkFork\System.ServiceModel\System\ServiceModel\Channels\BufferedWriteStream.cs (10)
178await _sem.WaitAsync().ConfigureAwait(false);
183await FlushWriteAsync(cancellationToken).ConfigureAwait(false);
189await _stream.FlushAsync(cancellationToken).ConfigureAwait(false);
215await _stream.WriteAsync(_buffer, 0, _writePos, cancellationToken).ConfigureAwait(false);
217await _stream.FlushAsync(cancellationToken).ConfigureAwait(false);
457await semaphoreLockTask.ConfigureAwait(false);
485await _stream.WriteAsync(_buffer, 0, _writePos, cancellationToken).ConfigureAwait(false);
508await _stream.WriteAsync(_buffer, 0, totalUserBytes, cancellationToken).ConfigureAwait(false);
513await _stream.WriteAsync(_buffer, 0, _writePos, cancellationToken).ConfigureAwait(false);
518await _stream.WriteAsync(array, offset, count, cancellationToken).ConfigureAwait(false);
Metadata\MetadataDocumentLoader.cs (10)
184await LoadAsync(this.MetadataSourceUrl.AbsoluteUri, string.Empty, Directory.GetCurrentDirectory(), cancellationToken).ConfigureAwait(false);
190await LoadAsync(fileUri.LocalPath, string.Empty, Directory.GetCurrentDirectory(), cancellationToken).ConfigureAwait(false);
223await LoadFromStreamAsync(fileStream, fileInfo.FullName, fileInfo.DirectoryName, cancellationToken).ConfigureAwait(false);
297await LoadAsXmlSchemaAsync(reader, uri, basePath, cancellationToken).ConfigureAwait(false);
300await LoadAsWsdlAsync(reader, uri, basePath, cancellationToken).ConfigureAwait(false);
306await LoadAsEPRAsync(reader, cancellationToken).ConfigureAwait(false);
326await LoadAsXmlSchemaIncludesAsync(schema, uri, basePath, cancellationToken).ConfigureAwait(false);
364await LoadAsXmlSchemaIncludesAsync(schema, wsdl.RetrievalUrl, basePath, cancellationToken).ConfigureAwait(false);
380await LoadAsync(schemaUri.LocalPath, baseUrl, basePath, cancellationToken).ConfigureAwait(false);
389await LoadFromStreamAsync(stream, schemaUri.AbsoluteUri, basePath, cancellationToken).ConfigureAwait(false);
Shared\MSBuildProj.cs (13)
682await SaveAsync(logger, cancellationToken).ConfigureAwait(false);
703await AsyncHelper.RunAsync(() => ProjectNode.Save(writer), cancellationToken).ConfigureAwait(false);
717await this.SaveAsync(logger, cancellationToken).ConfigureAwait(false);
773await safeLogger.WriteWarningAsync(Shared.Resources.WarningMultiFxOrNoSupportedDnxVersion, logToUI: true).ConfigureAwait(false);
777await safeLogger.WriteMessageAsync($"Resolved project reference count: {dependencies.Count()}", logToUI: false).ConfigureAwait(false);
839await safeLogger.WriteWarningAsync(Shared.Resources.WarningMultiFxOrNoSupportedDnxVersion, logToUI: true).ConfigureAwait(false);
844await safeLogger.WriteWarningAsync(Shared.Resources.WarningCannotResolveProjectReferences, logToUI: true).ConfigureAwait(false);
851await safeLogger.WriteWarningAsync(ex.Message, logToUI: false).ConfigureAwait(false);
855await safeLogger.WriteMessageAsync($"Package reference count: {packageDependencies.Count}", logToUI: false).ConfigureAwait(false);
932await safeLogger.WriteWarningAsync(ex.Message, logToUI: false).ConfigureAwait(false);
940await safeLogger.WriteWarningAsync("Deps file not found (project not built), unable to resolve assembly/project dependencies!", logToUI: false).ConfigureAwait(false);
943await safeLogger.WriteMessageAsync($"Assembly reference count: {assemblyDependencies.Count}", logToUI: false).ConfigureAwait(false);
1013await safeLogger.WriteMessageAsync($"deps file: {depsFile}", logToUI: false).ConfigureAwait(false);
GenerateDocumentationAndConfigFiles (31)
src\Dependencies\Threading\ProducerConsumer.cs (8)
37await consumeItems(items.ToImmutableAndClear(), args, cancellationToken).ConfigureAwait(false);
77await args.consumeItems(items.ReadAllAsync(cancellationToken), args.args, cancellationToken).ConfigureAwait(false);
114await args.consumeItems(items, args.args, cancellationToken).ConfigureAwait(false);
238await args.produceItems(source, callback, args.args, cancellationToken).ConfigureAwait(false)),
299source, callback, args.args, cancellationToken).ConfigureAwait(false)),
344await Task.WhenAll(writeTask, readTask).ConfigureAwait(false);
367await produceItems(item => channel.Writer.TryWrite(item), args, cancellationToken).ConfigureAwait(false);
384await action(args, cancellationToken).ConfigureAwait(false);
GenerateRulesMissingDocumentation (4)
http2cat (2)
HttpStress (1)
IdeCoreBenchmarks (2)
IdentitySample.PasskeyConformance (1)
IIS.Common.TestLib (2)
IIS.FunctionalTests (2)
IIS.LongTests (2)
IIS.NewHandler.FunctionalTests (2)
IIS.NewShim.FunctionalTests (2)
IIS.ShadowCopy.Tests (1)
IISExpress.FunctionalTests (2)
InMemory.FunctionalTests (29)
InteractiveHost.UnitTests (2)
InteractiveHost32 (1)
InteractiveHost64 (1)
InteropClient (4)
InteropWebsite (1)
LargeResponseApp (1)
Metrics (17)
src\Dependencies\Threading\ProducerConsumer.cs (8)
37await consumeItems(items.ToImmutableAndClear(), args, cancellationToken).ConfigureAwait(false);
77await args.consumeItems(items.ReadAllAsync(cancellationToken), args.args, cancellationToken).ConfigureAwait(false);
114await args.consumeItems(items, args.args, cancellationToken).ConfigureAwait(false);
238await args.produceItems(source, callback, args.args, cancellationToken).ConfigureAwait(false)),
299source, callback, args.args, cancellationToken).ConfigureAwait(false)),
344await Task.WhenAll(writeTask, readTask).ConfigureAwait(false);
367await produceItems(item => channel.Writer.TryWrite(item), args, cancellationToken).ConfigureAwait(false);
384await action(args, cancellationToken).ConfigureAwait(false);
Metrics.Legacy (17)
src\Dependencies\Threading\ProducerConsumer.cs (8)
37await consumeItems(items.ToImmutableAndClear(), args, cancellationToken).ConfigureAwait(false);
77await args.consumeItems(items.ReadAllAsync(cancellationToken), args.args, cancellationToken).ConfigureAwait(false);
114await args.consumeItems(items, args.args, cancellationToken).ConfigureAwait(false);
238await args.produceItems(source, callback, args.args, cancellationToken).ConfigureAwait(false)),
299source, callback, args.args, cancellationToken).ConfigureAwait(false)),
344await Task.WhenAll(writeTask, readTask).ConfigureAwait(false);
367await produceItems(item => channel.Writer.TryWrite(item), args, cancellationToken).ConfigureAwait(false);
384await action(args, cancellationToken).ConfigureAwait(false);
Microsoft.Agents.AI.ProjectTemplates.Tests (2)
Microsoft.Analyzers.Extra.Tests (1)
Microsoft.Analyzers.Local.Tests (1)
Microsoft.AspNetCore.Authorization (4)
Microsoft.AspNetCore.Components (1)
Microsoft.AspNetCore.Components.WebView.Maui (1)
Microsoft.AspNetCore.Diagnostics.Middleware (4)
Microsoft.AspNetCore.Diagnostics.Middleware.Tests (7)
Microsoft.AspNetCore.Hosting (5)
Microsoft.AspNetCore.Http.Connections.Client (29)
HttpConnection.cs (9)
204await StartAsyncCore(transferFormat, cancellationToken).ConfigureAwait(false);
218await _connectionLock.WaitAsync(cancellationToken).ConfigureAwait(false);
231await SelectAndStartTransport(transferFormat, cancellationToken).ConfigureAwait(false);
254await DisposeAsyncCore().ConfigureAwait(false);
265await _connectionLock.WaitAsync().ConfigureAwait(false);
276await _transport!.StopAsync().ConfigureAwait(false);
317await StartTransport(uri, _httpConnectionOptions.Transports, transferFormat, cancellationToken, useStatefulReconnect: false).ConfigureAwait(false);
415await StartTransport(connectUrl, transportType, transferFormat, cancellationToken, negotiationResponse.UseStatefulReconnect).ConfigureAwait(false);
527await transport.StartAsync(connectUrl, transferFormat, cancellationToken).ConfigureAwait(false);
Microsoft.AspNetCore.HttpLogging (1)
Microsoft.AspNetCore.Identity (2)
Microsoft.AspNetCore.Identity.EntityFrameworkCore (4)
Microsoft.AspNetCore.InternalTesting (23)
Microsoft.AspNetCore.Mvc.Testing (3)
Microsoft.AspNetCore.OutputCaching (1)
Microsoft.AspNetCore.OutputCaching.StackExchangeRedis (2)
Microsoft.AspNetCore.ResponseCaching (1)
Microsoft.AspNetCore.ResponseCompression (1)
Microsoft.AspNetCore.Server.HttpSys (1)
Microsoft.AspNetCore.Server.HttpSys.FunctionalTests (1)
Microsoft.AspNetCore.Server.IIS (1)
Microsoft.AspNetCore.Server.Kestrel.Core (22)
Microsoft.AspNetCore.Server.Kestrel.Core.Tests (7)
Microsoft.AspNetCore.Server.Kestrel.Transport.Quic (1)
Microsoft.AspNetCore.Shared.Tests (1)
Microsoft.AspNetCore.SignalR.Client.Core (55)
HubConnection.cs (51)
269await StartAsyncInner(cancellationToken).ConfigureAwait(false);
275await _state.WaitConnectionLockAsync(token: cancellationToken).ConfigureAwait(false);
292await StartAsyncCore(linkedToken).ConfigureAwait(false);
322await StopAsyncCore(disposing: false).ConfigureAwait(false);
338await StopAsyncCore(disposing: true).ConfigureAwait(false);
479await SendCoreAsyncCore(methodName, args, cancellationToken).ConfigureAwait(false);
526await HandshakeAsync(startingConnectionState, usedProtocolVersion, cancellationToken).ConfigureAwait(false);
546await SendHubMessage(startingConnectionState, PingMessage.Instance, cancellationToken).ConfigureAwait(false);
570await _state.WaitConnectionLockAsync(token: default).ConfigureAwait(false);
582await reconnectTask.ConfigureAwait(false);
583await _state.WaitConnectionLockAsync(token: default).ConfigureAwait(false);
659await connectionStateStopTask.ConfigureAwait(false);
706await _state.WaitConnectionLockAsync(token: default).ConfigureAwait(false);
714await SendHubMessage(_state.CurrentConnectionStateUnsynchronized, new CancelInvocationMessage(irq.InvocationId), cancellationToken: default).ConfigureAwait(false);
750await InvokeStreamCore(connectionState, methodName, irq, args, streamIds?.ToArray(), cancellationToken).ConfigureAwait(false);
909await SendStreamItemAsync(connectionState, streamId, enumerator.Current, tokenSource).ConfigureAwait(false);
945await SendStreamItemAsync(connectionState, streamId, item, tokenSource).ConfigureAwait(false);
960await SendStreamItemAsync(connectionState, streamId, streamValue, tokenSource).ConfigureAwait(false);
969await SendWithLock(connectionState, new StreamItemMessage(streamId, item), tokenSource.Token).ConfigureAwait(false);
982await createAndConsumeStream().ConfigureAwait(false);
997await _state.WaitConnectionLockAsync(token: default).ConfigureAwait(false);
1004await SendHubMessage(connectionState, CompletionMessage.WithError(streamId, responseError), cancellationToken: default).ConfigureAwait(false);
1095await InvokeCore(connectionState, methodName, irq, args, streamIds?.ToArray(), cancellationToken).ConfigureAwait(false);
1154await SendHubMessage(connectionState, invocationMessage, cancellationToken).ConfigureAwait(false);
1185await SendHubMessage(connectionState, invocationMessage, cancellationToken).ConfigureAwait(false);
1248await SendHubMessage(connectionState, invocationMessage, cancellationToken).ConfigureAwait(false);
1279await SendHubMessage(connectionState, message, cancellationToken).ConfigureAwait(false);
1307await SendWithLock(connectionState, CompletionMessage.WithError(bindingFailure.InvocationId, "Client failed to parse argument(s)."), cancellationToken: default).ConfigureAwait(false);
1336await DispatchInvocationStreamItemAsync(streamItem, irq).ConfigureAwait(false);
1362await connectionState.AckAsync(ackMessage).ConfigureAwait(false);
1385await SendWithLock(connectionState, CompletionMessage.WithError(invocation.InvocationId!, "Client didn't provide a result."), cancellationToken: default).ConfigureAwait(false);
1416await task.ConfigureAwait(false);
1435await SendWithLock(connectionState, CompletionMessage.WithError(invocation.InvocationId!, resultException.Message), cancellationToken: default).ConfigureAwait(false);
1439await SendWithLock(connectionState, CompletionMessage.WithResult(invocation.InvocationId!, result), cancellationToken: default).ConfigureAwait(false);
1444await SendWithLock(connectionState, CompletionMessage.WithError(invocation.InvocationId!, "Client didn't provide a result."), cancellationToken: default).ConfigureAwait(false);
1628await invokeTask.ConfigureAwait(false);
1713await timerTask.ConfigureAwait(false);
1715await HandleConnectionClose(connectionState).ConfigureAwait(false);
1736await _state.WaitConnectionLockAsync(token: default).ConfigureAwait(false);
1794await closed.Invoke(closeException).ConfigureAwait(false);
1849await Task.Delay(nextRetryDelay.Value, _state.StopCts.Token).ConfigureAwait(false);
1855await _state.WaitConnectionLockAsync(token: default).ConfigureAwait(false);
1870await _state.WaitConnectionLockAsync(token: default).ConfigureAwait(false);
1876await StartAsyncCore(_state.StopCts.Token).ConfigureAwait(false);
1911await _state.WaitConnectionLockAsync(token: default).ConfigureAwait(false);
1971await reconnecting.Invoke(closeException).ConfigureAwait(false);
1998await reconnected.Invoke(ConnectionId).ConfigureAwait(false);
2271await ((ReceiveTask ?? Task.CompletedTask).ConfigureAwait(false));
2296await RunTimerActions().ConfigureAwait(false);
2373await _hubConnection.SendHubMessage(this, PingMessage.Instance).ConfigureAwait(false);
2509await WaitConnectionLockAsync(token, methodName).ConfigureAwait(false);
Microsoft.AspNetCore.SignalR.Client.FunctionalTests (1)
Microsoft.AspNetCore.SignalR.Core (4)
Microsoft.AspNetCore.SignalR.Specification.Tests (2)
Microsoft.Build.Tasks.CodeAnalysis (11)
src\Compilers\Shared\BuildProtocol.cs (7)
128await ReadAllAsync(inStream, lengthBuffer, 4, cancellationToken).ConfigureAwait(false);
187cancellationToken).ConfigureAwait(false);
190await memoryStream.CopyToAsync(outStream, bufferSize: length, cancellationToken: cancellationToken).ConfigureAwait(false);
305cancellationToken).ConfigureAwait(false);
308await memoryStream.CopyToAsync(outStream, bufferSize: length, cancellationToken: cancellationToken).ConfigureAwait(false);
324await ReadAllAsync(stream, lengthBuffer, 4, cancellationToken).ConfigureAwait(false);
332cancellationToken).ConfigureAwait(false);
Microsoft.Build.Tasks.CodeAnalysis.Sdk (10)
src\Compilers\Shared\BuildProtocol.cs (7)
128await ReadAllAsync(inStream, lengthBuffer, 4, cancellationToken).ConfigureAwait(false);
187cancellationToken).ConfigureAwait(false);
190await memoryStream.CopyToAsync(outStream, bufferSize: length, cancellationToken: cancellationToken).ConfigureAwait(false);
305cancellationToken).ConfigureAwait(false);
308await memoryStream.CopyToAsync(outStream, bufferSize: length, cancellationToken: cancellationToken).ConfigureAwait(false);
324await ReadAllAsync(stream, lengthBuffer, 4, cancellationToken).ConfigureAwait(false);
332cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis (24)
DiagnosticAnalyzer\AnalyzerDriver.cs (12)
654await ExecutePrimaryAnalysisTaskAsync(analysisScope, usingPrePopulatedEventQueue: true, cancellationToken).ConfigureAwait(false);
708await WhenInitializedTask.ConfigureAwait(false);
716await ProcessCompilationEventsAsync(analysisScope, usingPrePopulatedEventQueue, cancellationToken).ConfigureAwait(false);
879await this.WhenCompletedTask.ConfigureAwait(false);
1553await Task.WhenAll(workerTasks.Concat(syntaxTreeActionsTask).Concat(additionalFileActionsTask)).ConfigureAwait(false);
1576await ProcessEventAsync(completedEvent, analysisScope, cancellationToken).ConfigureAwait(false);
1633await ProcessEventAsync(compilationEvent, analysisScope, cancellationToken).ConfigureAwait(false);
1663await OnEventProcessedCoreAsync(e, processedAnalyzers, analysisScope, cancellationToken).ConfigureAwait(false);
1675await onSymbolAndMembersProcessedAsync(symbolDeclaredEvent.Symbol, analyzer).ConfigureAwait(false);
1707await processContainerOnMemberCompletedAsync(symbol.ContainingNamespace, symbol, analyzer).ConfigureAwait(false);
1710await processContainerOnMemberCompletedAsync(type, symbol, analyzer).ConfigureAwait(false);
1720await OnEventProcessedCoreAsync(processedContainerEvent, ImmutableArray.Create(analyzer), analysisScope, cancellationToken).ConfigureAwait(false);
DiagnosticAnalyzer\CompilationWithAnalyzers.cs (11)
345await ComputeAnalyzerDiagnosticsAsync(analysisScope, cancellationToken).ConfigureAwait(false);
352await ComputeAnalyzerDiagnosticsAsync(analysisScope, cancellationToken).ConfigureAwait(false);
359await ComputeAnalyzerDiagnosticsAsync(analysisScope, cancellationToken).ConfigureAwait(false);
383await driver.WhenInitializedTask.ConfigureAwait(false);
580await ComputeAnalyzerDiagnosticsAsync(analysisScope, cancellationToken).ConfigureAwait(false);
587await ComputeAnalyzerDiagnosticsAsync(analysisScope, cancellationToken).ConfigureAwait(false);
654await ComputeAnalyzerDiagnosticsAsync(analysisScope, cancellationToken).ConfigureAwait(false);
661await ComputeAnalyzerDiagnosticsAsync(analysisScope, cancellationToken).ConfigureAwait(false);
759await driver.WhenCompletedTask.ConfigureAwait(false);
798await attachQueueAndProcessAllEventsAsync(builder, driver, cancellationToken).ConfigureAwait(false);
826await driver.AttachQueueAndProcessAllEventsAsync(eventQueue, analysisScope, cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.Analyzers (20)
src\Dependencies\Threading\ProducerConsumer.cs (8)
37await consumeItems(items.ToImmutableAndClear(), args, cancellationToken).ConfigureAwait(false);
77await args.consumeItems(items.ReadAllAsync(cancellationToken), args.args, cancellationToken).ConfigureAwait(false);
114await args.consumeItems(items, args.args, cancellationToken).ConfigureAwait(false);
238await args.produceItems(source, callback, args.args, cancellationToken).ConfigureAwait(false)),
299source, callback, args.args, cancellationToken).ConfigureAwait(false)),
344await Task.WhenAll(writeTask, readTask).ConfigureAwait(false);
367await produceItems(item => channel.Writer.TryWrite(item), args, cancellationToken).ConfigureAwait(false);
384await action(args, cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.AnalyzerUtilities (14)
src\Dependencies\Threading\ProducerConsumer.cs (8)
37await consumeItems(items.ToImmutableAndClear(), args, cancellationToken).ConfigureAwait(false);
77await args.consumeItems(items.ReadAllAsync(cancellationToken), args.args, cancellationToken).ConfigureAwait(false);
114await args.consumeItems(items, args.args, cancellationToken).ConfigureAwait(false);
238await args.produceItems(source, callback, args.args, cancellationToken).ConfigureAwait(false)),
299source, callback, args.args, cancellationToken).ConfigureAwait(false)),
344await Task.WhenAll(writeTask, readTask).ConfigureAwait(false);
367await produceItems(item => channel.Writer.TryWrite(item), args, cancellationToken).ConfigureAwait(false);
384await action(args, cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.BannedApiAnalyzers (20)
src\Dependencies\Threading\ProducerConsumer.cs (8)
37await consumeItems(items.ToImmutableAndClear(), args, cancellationToken).ConfigureAwait(false);
77await args.consumeItems(items.ReadAllAsync(cancellationToken), args.args, cancellationToken).ConfigureAwait(false);
114await args.consumeItems(items, args.args, cancellationToken).ConfigureAwait(false);
238await args.produceItems(source, callback, args.args, cancellationToken).ConfigureAwait(false)),
299source, callback, args.args, cancellationToken).ConfigureAwait(false)),
344await Task.WhenAll(writeTask, readTask).ConfigureAwait(false);
367await produceItems(item => channel.Writer.TryWrite(item), args, cancellationToken).ConfigureAwait(false);
384await action(args, cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.CodeStyle (16)
src\Dependencies\Threading\ProducerConsumer.cs (8)
37await consumeItems(items.ToImmutableAndClear(), args, cancellationToken).ConfigureAwait(false);
77await args.consumeItems(items.ReadAllAsync(cancellationToken), args.args, cancellationToken).ConfigureAwait(false);
114await args.consumeItems(items, args.args, cancellationToken).ConfigureAwait(false);
238await args.produceItems(source, callback, args.args, cancellationToken).ConfigureAwait(false)),
299source, callback, args.args, cancellationToken).ConfigureAwait(false)),
344await Task.WhenAll(writeTask, readTask).ConfigureAwait(false);
367await produceItems(item => channel.Writer.TryWrite(item), args, cancellationToken).ConfigureAwait(false);
384await action(args, cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.CodeStyle.Fixes (23)
src\Analyzers\Core\CodeFixes\GenerateVariable\AbstractGenerateVariableService.cs (4)
56await AddPropertyCodeActionsAsync(actions, semanticDocument, state, cancellationToken).ConfigureAwait(false);
62await AddPropertyCodeActionsAsync(actions, semanticDocument, state, cancellationToken).ConfigureAwait(false);
66await AddLocalCodeActionsAsync(actions, document, state, cancellationToken).ConfigureAwait(false);
67await AddParameterCodeActionsAsync(actions, document, state, cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.CSharp.CodeStyle.Fixes (18)
src\Analyzers\CSharp\CodeFixes\UseImplicitOrExplicitType\UseExplicitTypeCodeFixProvider.cs (4)
58await HandleDeclarationAsync(document, editor, node, cancellationToken).ConfigureAwait(false);
75await HandleVariableDeclarationAsync(document, editor, varDecl, cancellationToken).ConfigureAwait(false);
79await HandleForEachStatementAsync(document, editor, forEach, cancellationToken).ConfigureAwait(false);
83await HandleDeclarationExpressionAsync(document, editor, declarationExpression, cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.CSharp.CodeStyle.UnitTests (6)
Microsoft.CodeAnalysis.CSharp.EditorFeatures (2)
Microsoft.CodeAnalysis.CSharp.EditorFeatures.UnitTests (125)
CodeActions\MoveStaticMembers\CSharpMoveStaticMembersTests.cs (88)
54""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
84""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
120""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
156""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
210""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
240""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
276""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
316""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
362""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
408""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
466""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
502""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
538""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
559""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
583""", "Class1Helpers.cs", selectedMembers, "NewNs.Class1Helpers").ConfigureAwait(false);
619""", "Class1Helpers.cs", selectedMembers, "ExtraNs.Class1Helpers").ConfigureAwait(false);
668}.RunAsync().ConfigureAwait(false);
704""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
740""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
792""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
839""", "ClassWithStaticMembersHelpers.cs", selectedMembers, "ClassWithStaticMembersHelpers").ConfigureAwait(false);
893""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
938""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
977""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
1034""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
1086""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
1144""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
1200""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
1261""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
1323""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
1377""", "Class1Helpers.cs", selectedMembers, "ExtraNs.Class1Helpers").ConfigureAwait(false);
1457}.RunAsync().ConfigureAwait(false);
1520""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
1583""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
1677}.RunAsync().ConfigureAwait(false);
1737""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
1800""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
1863""", "Class1Helpers.cs", selectedMembers, "ExtraNs.Class1Helpers").ConfigureAwait(false);
1935""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
2024""", "Class1Helpers.cs", selectedMembers, "ExtraNs.Class1Helpers").ConfigureAwait(false);
2125""", "Class1Helpers.cs", selectedMembers, "ExtraNs.Class1Helpers").ConfigureAwait(false);
2161""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
2206""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
2239"Class1Helpers").ConfigureAwait(false);
2270"Class1Helpers").ConfigureAwait(false);
2307"Class1Helpers").ConfigureAwait(false);
2344"Class1Helpers").ConfigureAwait(false);
2399"Class1Helpers").ConfigureAwait(false);
2430"Class1Helpers").ConfigureAwait(false);
2479"TestNs.Class1Helpers").ConfigureAwait(false);
2522"TestNs.Class1Helpers").ConfigureAwait(false);
2568"Class1Helpers").ConfigureAwait(false);
2613"Class1Helpers").ConfigureAwait(false);
2659"WorkflowTypes").ConfigureAwait(false);
2699""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
2729""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
2759""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
2789""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
2819""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
2855""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
2885""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
2916""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
2957""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
2998""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
3039""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
3080""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
3111""", "Class1Helpers.cs", selectedMembers, "Class1Helpers").ConfigureAwait(false);
3125""").ConfigureAwait(false);
3140""").ConfigureAwait(false);
3157""").ConfigureAwait(false);
3174""").ConfigureAwait(false);
3194}.RunAsync().ConfigureAwait(false);
3211}.RunAsync().ConfigureAwait(false);
3228}.RunAsync().ConfigureAwait(false);
3245}.RunAsync().ConfigureAwait(false);
3262}.RunAsync().ConfigureAwait(false);
3276""").ConfigureAwait(false);
3290""").ConfigureAwait(false);
3306""").ConfigureAwait(false);
3322""").ConfigureAwait(false);
3339""").ConfigureAwait(false);
3357}.RunAsync().ConfigureAwait(false);
3375}.RunAsync().ConfigureAwait(false);
3396}.RunAsync().ConfigureAwait(false);
3473}.RunAsync().ConfigureAwait(false);
3493}.RunAsync().ConfigureAwait(false);
3518await test.RunAsync().ConfigureAwait(false);
3526}.RunAsync().ConfigureAwait(false);
Formatting\Indentation\SmartIndenterEnterOnTokenTests.cs (4)
1302await AssertIndentUsingSmartTokenFormatterAsync(code, ch, indentationLine, expectedIndentation, useTabs: false).ConfigureAwait(false);
1303await AssertIndentUsingSmartTokenFormatterAsync(code.Replace(" ", "\t"), ch, indentationLine, expectedIndentation, useTabs: true).ConfigureAwait(false);
1342await AssertIndentNotUsingSmartTokenFormatterButUsingIndenterAsync(code, indentationLine, expectedIndentation, useTabs: false, indentStyle).ConfigureAwait(false);
1343await AssertIndentNotUsingSmartTokenFormatterButUsingIndenterAsync(code.Replace(" ", "\t"), indentationLine, expectedIndentation, useTabs: true, indentStyle).ConfigureAwait(false);
Formatting\Indentation\SmartTokenFormatterFormatRangeTests.cs (2)
3099await AutoFormatOnMarkerAsync(initialMarkup, expected, useTabs: false, tokenKind, startTokenKind).ConfigureAwait(false);
3100await AutoFormatOnMarkerAsync(initialMarkup.Replace(" ", "\t"), expected.Replace(" ", "\t"), useTabs: true, tokenKind, startTokenKind).ConfigureAwait(false);
Formatting\Indentation\SmartTokenFormatterFormatTokenTests.cs (12)
510await AssertSmartTokenFormatterOpenBraceWithBaseIndentationAsync(markup, baseIndentation, expectedIndentation, useTabs: false).ConfigureAwait(false);
511await AssertSmartTokenFormatterOpenBraceWithBaseIndentationAsync(markup.Replace(" ", "\t"), baseIndentation, expectedIndentation, useTabs: true).ConfigureAwait(false);
535await AssertSmartTokenFormatterOpenBraceAsync(code, indentationLine, expectedSpace, useTabs: false, baseIndentation, span).ConfigureAwait(false);
536await AssertSmartTokenFormatterOpenBraceAsync(code.Replace(" ", "\t"), indentationLine, expectedSpace, useTabs: true, baseIndentation, span).ConfigureAwait(false);
556await AssertSmartTokenFormatterOpenBraceAsync(expected, code, indentationLine, useTabs: false).ConfigureAwait(false);
557await AssertSmartTokenFormatterOpenBraceAsync(expected.Replace(" ", "\t"), code.Replace(" ", "\t"), indentationLine, useTabs: true).ConfigureAwait(false);
577await AssertSmartTokenFormatterCloseBraceWithBaseIndentation(markup, baseIndentation, expectedIndentation, useTabs: false).ConfigureAwait(false);
578await AssertSmartTokenFormatterCloseBraceWithBaseIndentation(markup.Replace(" ", "\t"), baseIndentation, expectedIndentation, useTabs: true).ConfigureAwait(false);
602await AssertSmartTokenFormatterCloseBraceAsync(code, indentationLine, expectedSpace, useTabs: false, baseIndentation, span).ConfigureAwait(false);
603await AssertSmartTokenFormatterCloseBraceAsync(code.Replace(" ", "\t"), indentationLine, expectedSpace, useTabs: true, baseIndentation, span).ConfigureAwait(false);
622await ExpectException_SmartTokenFormatterCloseBraceAsync(code, indentationLine, useTabs: false).ConfigureAwait(false);
623await ExpectException_SmartTokenFormatterCloseBraceAsync(code.Replace(" ", "\t"), indentationLine, useTabs: true).ConfigureAwait(false);
Microsoft.CodeAnalysis.CSharp.Features (31)
src\Analyzers\CSharp\CodeFixes\UseImplicitOrExplicitType\UseExplicitTypeCodeFixProvider.cs (4)
58await HandleDeclarationAsync(document, editor, node, cancellationToken).ConfigureAwait(false);
75await HandleVariableDeclarationAsync(document, editor, varDecl, cancellationToken).ConfigureAwait(false);
79await HandleForEachStatementAsync(document, editor, forEach, cancellationToken).ConfigureAwait(false);
83await HandleDeclarationExpressionAsync(document, editor, declarationExpression, cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.CSharp.Features.UnitTests (8)
Microsoft.CodeAnalysis.CSharp.Workspaces (2)
Microsoft.CodeAnalysis.EditorFeatures (72)
Classification\Semantic\AbstractSemanticOrEmbeddedClassificationViewTaggerProvider.cs (5)
110context, spanToTag, classificationService, classificationOptions, cancellationToken).ConfigureAwait(false);
135context, document, spanToTag.SnapshotSpan, classificationService, options, currentSemanticVersion, cancellationToken).ConfigureAwait(false);
209context, document, subSpanToTag, classificationService, options, currentSemanticVersion, cancellationToken).ConfigureAwait(false);
241document, span.ToTextSpan(), options, classifiedSpans, cancellationToken).ConfigureAwait(false);
246document, span.ToTextSpan(), options, classifiedSpans, cancellationToken).ConfigureAwait(false);
GoOrFind\AbstractGoOrFindNavigationService.cs (5)
132document, service, position, allowInvalidPosition, cancellationTokenSource).ConfigureAwait(false);
197await PresentResultsInStreamingPresenterAsync(document, findContext, findTask, cancellationTokenSource).ConfigureAwait(false);
234await findContext.AttachToStreamingPresenterAsync(presenterContext, cancellationToken).ConfigureAwait(false);
242await findTask.ConfigureAwait(false);
288await FindActionAsync(findContext, document, service, position, cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.EditorFeatures.Test.Utilities (1)
Microsoft.CodeAnalysis.EditorFeatures.UnitTests (5)
InheritanceMargin\InheritanceMarginTests.cs (4)
64await VerifyTestMemberInDocumentAsync(testWorkspace, testHostDocument, memberItems, cancellationToken).ConfigureAwait(false);
95await VerifyTestMemberInDocumentAsync(testWorkspace, testHostDocument, memberItems, cancellationToken).ConfigureAwait(false);
222await VerifyTestMemberInDocumentAsync(testWorkspace, testHostDocument1, memberItemsInMarkup1, cancellationToken).ConfigureAwait(false);
223await VerifyTestMemberInDocumentAsync(testWorkspace, testHostDocument2, memberItemsInMarkup2, cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.ExternalAccess.Copilot (1)
Microsoft.CodeAnalysis.ExternalAccess.Debugger (1)
Microsoft.CodeAnalysis.ExternalAccess.Extensions (1)
Microsoft.CodeAnalysis.ExternalAccess.FSharp (5)
Microsoft.CodeAnalysis.ExternalAccess.OmniSharp (1)
Microsoft.CodeAnalysis.ExternalAccess.Razor.Features (2)
Microsoft.CodeAnalysis.ExternalAccess.Xaml (2)
Microsoft.CodeAnalysis.Features (257)
AddImport\AbstractAddImportFeatureService.cs (6)
185await FindResultsInAllSymbolsInStartingProjectAsync(allReferences, finder, exact, cancellationToken).ConfigureAwait(false);
194await FindResultsInUnreferencedProjectSourceSymbolsAsync(projectToAssembly, project, allReferences, maxResults, finder, exact, cancellationToken).ConfigureAwait(false);
198await FindResultsInUnreferencedMetadataSymbolsAsync(referenceToCompilation, project, allReferences, maxResults, finder, exact, cancellationToken).ConfigureAwait(false);
202await finder.FindNugetOrReferenceAssemblyReferencesAsync(allReferences, exact, cancellationToken).ConfigureAwait(false);
251linkedTokenSource.Token).ConfigureAwait(false);
308linkedTokenSource.Token).ConfigureAwait(false);
AddImport\SymbolReferenceFinder_PackageAssemblySearch.cs (5)
47await FindWorkerAsync(new(typeQuery.Name + AttributeSuffix, typeQuery.Arity), namespaceQuery, isAttributeSearch: true).ConfigureAwait(false);
49await FindWorkerAsync(typeQuery, namespaceQuery, isAttributeSearch: false).ConfigureAwait(false);
60allReferences, nameNode, typeQuery, namespaceQuery, isAttributeSearch, cancellationToken).ConfigureAwait(false);
67sourceName, sourceUrl, allReferences, nameNode, typeQuery, namespaceQuery, isAttributeSearch, cancellationToken).ConfigureAwait(false);
147cancellationToken: cancellationToken).ConfigureAwait(false);
ConvertTupleToStruct\AbstractConvertTupleToStructCodeRefactoringProvider.cs (4)
312containingNamespace, parameterNamingRule, isRecord, cancellationToken).ConfigureAwait(false);
316documentToEditorMap, cancellationToken).ConfigureAwait(false);
471project, result, tupleFieldNames, cancellationToken).ConfigureAwait(false);
484project, result, tupleFieldNames, cancellationToken).ConfigureAwait(false);
DesignerAttribute\DesignerAttributeDiscoveryService.cs (3)
145frozenProject, frozenDocument, callback, lazyProjectVersion, cancellationToken).ConfigureAwait(false);
172await ProcessProjectAsync(frozenSolution.GetRequiredProject(projectId), callback, cancellationToken).ConfigureAwait(false);
193project, specificDocument: null, callback, lazyProjectVersion, cancellationToken).ConfigureAwait(false);
Diagnostics\Service\DiagnosticAnalyzerService.IncrementalMemberEditAnalyzer.cs (6)
120await ExecuteCompilerAnalyzerAsync(compilerAnalyzerData, oldMemberSpans, builder).ConfigureAwait(false);
121await ExecuteSpanBasedAnalyzersAsync(spanBasedAnalyzers, oldMemberSpans, builder).ConfigureAwait(false);
122await ExecuteDocumentBasedAnalyzersAsync(documentBasedAnalyzers, oldMemberSpans, builder).ConfigureAwait(false);
144await ExecuteAnalyzersAsync(executor, analyzers, oldMemberSpans, builder).ConfigureAwait(false);
156await ExecuteAnalyzersAsync(executor, analyzers, oldMemberSpans, builder).ConfigureAwait(false);
168await ExecuteAnalyzersAsync(executor, analyzers, oldMemberSpans, builder).ConfigureAwait(false);
Diagnostics\Service\DiagnosticAnalyzerService_CoreAnalyze.cs (4)
155document, documentAnalysisScope.Span, diagnosticsBuilder.Add, cancellationToken).ConfigureAwait(false);
169document, span: null, callback, cancellationToken).ConfigureAwait(false);
181document, span: null, diagnosticsBuilder.Add, cancellationToken).ConfigureAwait(false);
200semanticModel, span, hostCompilationWithAnalyzers, analyzerInfoCache.GetDiagnosticDescriptors, reportDiagnostic, cancellationToken).ConfigureAwait(false);
DocumentHighlighting\AbstractDocumentHighlightsService.cs (5)
127documentsToSearch, options, cancellationToken).ConfigureAwait(false);
228await AddLocationSpanAsync(symbol.Locations.First(), solution, spanSet, tagMap, HighlightSpanKind.Definition, cancellationToken).ConfigureAwait(false);
254await AddLocationSpanAsync(location, solution, spanSet, tagMap, HighlightSpanKind.Definition, cancellationToken).ConfigureAwait(false);
263await AddLocationSpanAsync(referenceLocation.Location, solution, spanSet, tagMap, referenceKind, cancellationToken).ConfigureAwait(false);
270await AddLocationSpanAsync(location, solution, spanSet, tagMap, HighlightSpanKind.Reference, cancellationToken).ConfigureAwait(false);
ExternalAccess\UnitTesting\SolutionCrawler\UnitTestingWorkCoordinator.cs (19)
228await EnqueueFullProjectWorkItemAsync(addedProject, UnitTestingInvocationReasons.DocumentAdded).ConfigureAwait(false);
233await EnqueueWorkItemAsync(projectChanges).ConfigureAwait(continueOnCapturedContext: false);
238await EnqueueFullProjectWorkItemAsync(removedProject, UnitTestingInvocationReasons.DocumentRemoved).ConfigureAwait(false);
250await EnqueueFullProjectWorkItemAsync(solution.GetRequiredProject(projectId), invocationReasons).ConfigureAwait(false);
263await EnqueueWorkItemAsync(newProject.GetChanges(oldProject)).ConfigureAwait(false);
292await EnqueueChangedDocumentWorkItemAsync(oldProject.GetRequiredDocument(documentId), newProject.GetRequiredDocument(documentId)).ConfigureAwait(false);
323await EnqueueChangedDocumentWorkItemAsync(oldDocument, newDocument).ConfigureAwait(continueOnCapturedContext: false);
372await EnqueueDocumentWorkItemAsync(project, documentId, document: null, invocationReasons).ConfigureAwait(false);
375await EnqueueDocumentWorkItemAsync(project, documentId, document: null, invocationReasons).ConfigureAwait(false);
378await EnqueueDocumentWorkItemAsync(project, documentId, document: null, invocationReasons).ConfigureAwait(false);
383await EnqueueDocumentWorkItemAsync(project, document.Id, document, invocationReasons).ConfigureAwait(false);
393await EnqueueWorkItemAsync(analyzer, project, documentId, document: null, invocationReasons).ConfigureAwait(false);
410await EnqueueProjectConfigurationChangeWorkItemAsync(projectChanges).ConfigureAwait(false);
413await EnqueueDocumentWorkItemAsync(projectChanges.NewProject, addedDocumentId, document: null, UnitTestingInvocationReasons.DocumentAdded).ConfigureAwait(false);
418.ConfigureAwait(continueOnCapturedContext: false);
422await EnqueueDocumentWorkItemAsync(projectChanges.OldProject, removedDocumentId, document: null, UnitTestingInvocationReasons.DocumentRemoved).ConfigureAwait(false);
455await EnqueueFullProjectWorkItemAsync(projectChanges.NewProject, projectConfigurationChange).ConfigureAwait(false);
467await EnqueueDocumentWorkItemAsync(newDocument.Project, newDocument.Id, newDocument, UnitTestingInvocationReasons.DocumentChanged).ConfigureAwait(false);
474await EnqueueDocumentWorkItemAsync(newDocument.Project, newDocument.Id, newDocument, differenceResult.ChangeType, differenceResult.ChangedMember).ConfigureAwait(false);
ExternalAccess\UnitTesting\SolutionCrawler\UnitTestingWorkCoordinator.UnitTestingNormalPriorityProcessor.cs (7)
116await WaitForHigherPriorityOperationsAsync().ConfigureAwait(false);
140await ProcessDocumentAsync(Analyzers, workItem, documentCancellation).ConfigureAwait(false);
210await ProcessReanalyzeDocumentAsync(workItem, textDocument, cancellationToken).ConfigureAwait(false);
212await Processor.ProcessDocumentAnalyzersAsync(textDocument, analyzers, workItem, cancellationToken).ConfigureAwait(false);
218await RemoveDocumentAsync(documentId, cancellationToken).ConfigureAwait(false);
278c), cancellationToken).ConfigureAwait(false);
296await analyzer.RemoveDocumentAsync(documentId, cancellationToken).ConfigureAwait(false);
FindUsages\AbstractFindUsagesService_FindReferences.cs (6)
26definitionTrackingContext, document, position, classificationOptions, cancellationToken).ConfigureAwait(false);
62context, document, position, classificationOptions, cancellationToken).ConfigureAwait(false);
100context, symbol, project, classificationOptions, cancellationToken).ConfigureAwait(false);
121await FindReferencesAsync(context, symbol, project, searchOptions, classificationOptions, cancellationToken).ConfigureAwait(false);
152context, symbol, project, searchOptions, classificationOptions, cancellationToken).ConfigureAwait(false);
239tokenValue, Type.GetTypeCode(tokenValue.GetType()), solution, progressAdapter, cancellationToken).ConfigureAwait(false);
InlineHints\AbstractInlineHintsService.cs (2)
28await inlineParameterService.AddInlineHintsAsync(document, textSpan, options.ParameterOptions, options.DisplayOptions, displayAllOverride, result, cancellationToken).ConfigureAwait(false);
33await inlineTypeService.AddInlineHintsAsync(document, textSpan, options.TypeOptions, options.DisplayOptions, displayAllOverride, result, cancellationToken).ConfigureAwait(false);
NavigateTo\AbstractNavigateToSearchService.CachedDocumentSearch.cs (4)
96storageService, documentKeys, priorityDocumentKeys, searchPattern, kinds, onItemsFound, onProjectCompleted, cancellationToken).ConfigureAwait(false);
126ProcessSingleProjectGroupAsync, onItemsFound, args: default, cancellationToken).ConfigureAwait(false);
153}).ConfigureAwait(false);
156await onProjectCompleted().ConfigureAwait(false);
NavigateTo\AbstractNavigateToSearchService.GeneratedDocumentSearch.cs (4)
57projects, searchPattern, kinds, onItemsFound, onProjectCompleted, cancellationToken).ConfigureAwait(false);
72projects, ProcessSingleProjectAsync, onItemsFound, args: default, cancellationToken).ConfigureAwait(false);
85document, patternName, patternContainerOpt, declaredSymbolInfoKindsSet, onItemFound, cancellationToken)).ConfigureAwait(false);
87await onProjectCompleted().ConfigureAwait(false);
NavigateTo\AbstractNavigateToSearchService.NormalSearch.cs (7)
50await SearchDocumentAndRelatedDocumentsInCurrentProcessAsync(document, searchPattern, kinds, onItemsFound, cancellationToken).ConfigureAwait(false);
69SearchRelatedDocumentsInCurrentProcessAsync()).ConfigureAwait(false);
97await SearchDocumentsInCurrentProcessAsync(relatedDocuments).ConfigureAwait(false);
183projects, priorityDocuments, searchPattern, kinds, onItemsFound, onProjectCompleted, cancellationToken).ConfigureAwait(false);
208SearchSingleProjectAsync, onItemsFound, args: default, cancellationToken).ConfigureAwait(false);
223document, patternName, patternContainerOpt, declaredSymbolInfoKindsSet, onItemFound, cancellationToken)).ConfigureAwait(false);
225await onProjectCompleted().ConfigureAwait(false);
NavigateTo\NavigateToSearcher.cs (19)
149await SearchCurrentDocumentAsync(cancellationToken).ConfigureAwait(false);
153await SearchCurrentProjectAsync(documentSupport, cancellationToken).ConfigureAwait(false);
166await SearchAllProjectsAsync(isFullyLoaded, documentSupport, cancellationToken).ConfigureAwait(false);
176await ProgressItemsCompletedAsync(_remainingProgressItems, cancellationToken).ConfigureAwait(false);
192await AddProgressItemsAsync(1, cancellationToken).ConfigureAwait(false);
196cancellationToken).ConfigureAwait(false);
226await SearchSpecificProjectsAsync(isFullyLoaded, documentSupport, orderedProjects, cancellationToken).ConfigureAwait(false);
252cancellationToken).ConfigureAwait(false);
255await SearchFullyLoadedProjectsAsync(orderedProjects, seenItems, cancellationToken).ConfigureAwait(false);
258await SearchGeneratedDocumentsAsync(orderedProjects, seenItems, cancellationToken).ConfigureAwait(false);
266await AddProgressItemsAsync(projectCount, cancellationToken).ConfigureAwait(false);
267await SearchCachedDocumentsAsync(orderedProjects, seenItems, cancellationToken).ConfigureAwait(false);
373SearchCoreAsync).ConfigureAwait(false);
408() => this.ProgressItemsCompletedAsync(count: 1, cancellationToken)).ConfigureAwait(false);
450await onProjectCompleted().ConfigureAwait(false);
456onResultsFound, onProjectCompleted, cancellationToken).ConfigureAwait(false);
507await onProjectCompleted().ConfigureAwait(false);
512_solution, projects, _searchPattern, _kinds, _activeDocument, onResultsFound, onProjectCompleted, cancellationToken).ConfigureAwait(false);
538await onProjectCompleted().ConfigureAwait(false);
SpellCheck\AbstractSpellCheckCodeFixProvider.cs (5)
50await CheckNodeAsync(context, document, node, cancellationToken).ConfigureAwait(false);
58await CheckTokenAsync(context, document, token, cancellationToken).ConfigureAwait(false);
83await CreateSpellCheckCodeIssueAsync(context, token, IsGeneric(name), cancellationToken).ConfigureAwait(false);
100await CreateSpellCheckCodeIssueAsync(context, token, IsGeneric(token), cancellationToken).ConfigureAwait(false);
142completionList, similarityChecker).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\GenerateVariable\AbstractGenerateVariableService.cs (4)
56await AddPropertyCodeActionsAsync(actions, semanticDocument, state, cancellationToken).ConfigureAwait(false);
62await AddPropertyCodeActionsAsync(actions, semanticDocument, state, cancellationToken).ConfigureAwait(false);
66await AddLocalCodeActionsAsync(actions, document, state, cancellationToken).ConfigureAwait(false);
67await AddParameterCodeActionsAsync(actions, document, state, cancellationToken).ConfigureAwait(false);
SymbolSearch\Windows\SymbolSearchUpdateEngine.Update.cs (12)
124await Task.Delay(delayUntilNextUpdate, cancellationToken).ConfigureAwait(false);
295await WriteDatabaseTextFileAsync(databaseFileInfo, bytes, cancellationToken).ConfigureAwait(false);
296await WriteDatabaseBinaryFileAsync(database, databaseFileInfo, cancellationToken).ConfigureAwait(false);
307await WriteDatabaseFileAsync(databaseFileInfo, new ArraySegment<byte>(bytes), cancellationToken).ConfigureAwait(false);
333await WriteDatabaseFileAsync(databaseBinaryFileInfo, arraySegmentBuffer, cancellationToken).ConfigureAwait(false);
382}, cancellationToken).ConfigureAwait(false);
502await WriteDatabaseBinaryFileAsync(_service._sourceToDatabase[_source].Database, databaseFileInfo, cancellationToken).ConfigureAwait(false);
529await WriteDatabaseTextFileAsync(databaseFileInfo, finalBytes, cancellationToken).ConfigureAwait(false);
530await WriteDatabaseBinaryFileAsync(database, databaseFileInfo, cancellationToken).ConfigureAwait(false);
600await Task.Delay(delay, cancellationToken).ConfigureAwait(false);
681await Task.Delay(delay, cancellationToken).ConfigureAwait(false);
731await deflateStream.CopyToAsync(outStream, cancellationToken).ConfigureAwait(false);
ValueTracking\ValueTracker.cs (13)
52await TrackVariableReferencesAsync(symbol, operationCollector, cancellationToken).ConfigureAwait(false);
59await AddItemsFromAssignmentAsync(document, node, operationCollector, cancellationToken).ConfigureAwait(false);
90await TrackVariableDefinitionsAsync(symbol, operationCollector, cancellationToken).ConfigureAwait(false);
91await TrackVariableReferencesAsync(symbol, operationCollector, cancellationToken).ConfigureAwait(false);
117await TrackVariableReferencesAsync(parameterSymbol, operationCollector, cancellationToken).ConfigureAwait(false);
122await TrackParameterSymbolAsync(parameterSymbol, operationCollector, cancellationToken).ConfigureAwait(false);
131await TrackMethodSymbolAsync(methodSymbol, operationCollector, cancellationToken).ConfigureAwait(false);
161await collector.VisitAsync(assignmentOperation, cancellationToken).ConfigureAwait(false);
171documents: null, FindReferencesSearchOptions.Default, cancellationToken).ConfigureAwait(false);
185documents: null, FindReferencesSearchOptions.Default, cancellationToken).ConfigureAwait(false);
226await collector.VisitAsync(operation, cancellationToken).ConfigureAwait(false);
239await TrackVariableReferencesAsync(outOrRefParam, collector, cancellationToken).ConfigureAwait(false);
316await collector.VisitAsync(initializer, cancellationToken).ConfigureAwait(false);
ValueTracking\ValueTracker.FindReferencesProgress.cs (8)
54await TrackConstructorAsync(location, cancellationToken).ConfigureAwait(false);
60await TrackMethodInvocationArgumentsAsync(location, cancellationToken).ConfigureAwait(false);
79await AddItemsFromAssignmentAsync(location.Document, node, _operationCollector, cancellationToken).ConfigureAwait(false);
90await _operationCollector.VisitAsync(operation, cancellationToken).ConfigureAwait(false);
118await _operationCollector.VisitAsync(argumentOperation, cancellationToken).ConfigureAwait(false);
136await _operationCollector.VisitAsync(expressionOperation, cancellationToken).ConfigureAwait(false);
164await _operationCollector.VisitAsync(operation, cancellationToken).ConfigureAwait(false);
199await _operationCollector.VisitAsync(operation, cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.InteractiveHost (9)
Microsoft.CodeAnalysis.LanguageServer (1)
Microsoft.CodeAnalysis.LanguageServer.Protocol (54)
Features\Suggestions\UnifiedSuggestedActionsSource.cs (4)
73await GroupFixesAsync(project, fixCollections, map, order, cancellationToken).ConfigureAwait(false);
91await ProcessFixCollectionAsync(project, map, order, fixCollection, cancellationToken).ConfigureAwait(false);
107await AddCodeActionsAsync(project, map, order, fixCollection, GetFlavorsAsync, nonSupressionCodeFixes).ConfigureAwait(false);
111await AddCodeActionsAsync(project, map, order, fixCollection, GetFlavorsAsync, supressionCodeFixes).ConfigureAwait(false);
Handler\References\FindAllReferencesHandler.cs (2)
64await FindReferencesAsync(progress, workspace, document, linePosition, clientCapabilities.HasVisualStudioLspCapability(), includeDeclaration, _globalOptions, _metadataAsSourceFileService, _asyncListener, cancellationToken).ConfigureAwait(false);
89await findUsagesService.FindReferencesAsync(findUsagesContext, document, position, classificationOptions, cancellationToken).ConfigureAwait(false);
Handler\SemanticTokens\SemanticTokensHelpers.cs (3)
52await semanticTokensRefreshQueue.TryEnqueueRefreshComputationAsync(project, cancellationToken).ConfigureAwait(false);
95classifiedSpans, document, textSpans, options, cancellationToken).ConfigureAwait(false);
125classifiedSpans, document, textSpans, options, includeAdditiveSpans: true, cancellationToken).ConfigureAwait(false);
src\LanguageServer\Microsoft.CommonLanguageServerProtocol.Framework\RequestExecutionQueue.cs (6)
274await InvokeProcessCoreAsync(work, metadata, handler, methodInfo, concurrentlyExecutingTasks, currentWorkCts, cancellationToken).ConfigureAwait(false);
293await _languageServer.ShutdownAsync(message).ConfigureAwait(false);
294await _languageServer.ExitAsync().ConfigureAwait(false);
322await task.ConfigureAwait(false);
369await WrapStartRequestTaskAsync(work.StartRequestAsync<TRequest, TResponse>(deserializedRequest, context, handler, metadata.Language, cancellationToken), rethrowExceptions: true).ConfigureAwait(false);
472await _queue._queueProcessingTask.ConfigureAwait(false);
Microsoft.CodeAnalysis.LanguageServer.Protocol.UnitTests (31)
Microsoft.CodeAnalysis.LanguageServer.UnitTests (5)
Microsoft.CodeAnalysis.PerformanceSensitiveAnalyzers (20)
Microsoft.CodeAnalysis.PublicApiAnalyzers (14)
src\Dependencies\Threading\ProducerConsumer.cs (8)
37await consumeItems(items.ToImmutableAndClear(), args, cancellationToken).ConfigureAwait(false);
77await args.consumeItems(items.ReadAllAsync(cancellationToken), args.args, cancellationToken).ConfigureAwait(false);
114await args.consumeItems(items, args.args, cancellationToken).ConfigureAwait(false);
238await args.produceItems(source, callback, args.args, cancellationToken).ConfigureAwait(false)),
299source, callback, args.args, cancellationToken).ConfigureAwait(false)),
344await Task.WhenAll(writeTask, readTask).ConfigureAwait(false);
367await produceItems(item => channel.Writer.TryWrite(item), args, cancellationToken).ConfigureAwait(false);
384await action(args, cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.Remote.ServiceHub (44)
Host\RemoteWorkspace.SolutionCreator.cs (7)
137await ValidateChecksumAsync(newSolutionChecksum, solution, newSolutionChecksums.ProjectConeId, cancellationToken).ConfigureAwait(false);
222cancellationToken).ConfigureAwait(false);
248assetPath: AssetPathKind.ProjectAttributes, projectItemChecksums, cancellationToken).ConfigureAwait(false);
255assetPath: AssetPathKind.ProjectCompilationOptions, projectItemChecksums, cancellationToken).ConfigureAwait(false);
461assetPath: new(AssetPathKind.DocumentAttributes, project.Id), newChecksumsToSync, cancellationToken).ConfigureAwait(false);
467assetPath: new(AssetPathKind.DocumentText, project.Id), newChecksumsToSync, cancellationToken).ConfigureAwait(false);
626await TestUtils.AssertChecksumsAsync(_assetProvider, checksumFromRequest, workspace.CurrentSolution, incrementalSolutionBuilt, projectConeId).ConfigureAwait(false);
Host\TestUtils.cs (12)
161await solution.AppendAssetMapAsync(map, projectConeId, cancellationToken).ConfigureAwait(false);
173await project.AppendAssetMapAsync(map, cancellationToken).ConfigureAwait(false);
193await compilationChecksums.FindAsync(solution.CompilationState, projectCone: null, AssetPath.FullLookupForTesting, Flatten(compilationChecksums), callback, map, cancellationToken).ConfigureAwait(false);
198await compilationChecksums.FindAsync(solution.CompilationState, projectCone: null, AssetPath.FullLookupForTesting, Flatten(documentChecksums), callback, map, cancellationToken).ConfigureAwait(false);
203await solutionChecksums.FindAsync(solution.CompilationState.SolutionState, projectCone: null, AssetPath.FullLookupForTesting, Flatten(solutionChecksums), callback, map, cancellationToken).ConfigureAwait(false);
206await project.AppendAssetMapAsync(map, cancellationToken).ConfigureAwait(false);
211await compilationChecksums.FindAsync(solution.CompilationState, projectCone, AssetPath.SolutionAndProjectForTesting(projectId), Flatten(compilationChecksums), callback, map, cancellationToken).ConfigureAwait(false);
215await solutionChecksums.FindAsync(solution.CompilationState.SolutionState, projectCone, AssetPath.SolutionAndProjectForTesting(projectId), Flatten(solutionChecksums), callback, map, cancellationToken).ConfigureAwait(false);
218await project.AppendAssetMapAsync(map, cancellationToken).ConfigureAwait(false);
220await solution.GetRequiredProject(dep).AppendAssetMapAsync(map, cancellationToken).ConfigureAwait(false);
234await projectChecksums.FindAsync(project.State, AssetPath.FullLookupForTesting, Flatten(projectChecksums), callback, map, cancellationToken).ConfigureAwait(false);
239await documentChecksums.FindAsync(AssetPathKind.Documents, document.State, Flatten(documentChecksums), callback, map, cancellationToken).ConfigureAwait(false);
Services\NavigateToSearch\RemoteNavigateToSearchService.cs (4)
62document, searchPattern, kinds.ToImmutableHashSet(), onItemsFound, cancellationToken).ConfigureAwait(false);
83projects, priorityDocuments, searchPattern, kinds.ToImmutableHashSet(), onItemsFound, onProjectCompleted, cancellationToken).ConfigureAwait(false);
101projects, searchPattern, kinds.ToImmutableHashSet(), onItemsFound, onProjectCompleted, cancellationToken).ConfigureAwait(false);
121storageService, documentKeys, priorityDocumentKeys, searchPattern, kinds.ToImmutableHashSet(), onItemsFound, onProjectCompleted, cancellationToken).ConfigureAwait(false);
Services\SemanticClassification\RemoteSemanticClassificationService.Caching.cs (3)
118document, type, options, cancellationToken).ConfigureAwait(false);
156await classificationService.AddSemanticClassificationsAsync(document, fullSpan, options, classifiedSpans, cancellationToken).ConfigureAwait(false);
160await classificationService.AddEmbeddedLanguageClassificationsAsync(document, fullSpan, options, classifiedSpans, cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.Remote.Workspaces (14)
SolutionAssetStorage.Scope.cs (4)
55await FindAssetsAsync(assetPath, checksumsToFind, onAssetFound, arg, cancellationToken).ConfigureAwait(false);
78await stateChecksums.FindAsync(solutionState, this.ProjectCone, assetPath, remainingChecksumsToFind, onAssetFound, arg, cancellationToken).ConfigureAwait(false);
84await stateChecksums.FindAsync(solutionState, this.ProjectCone, assetPath, remainingChecksumsToFind, onAssetFound, arg, cancellationToken).ConfigureAwait(false);
110}, default(VoidResult), cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.ResxSourceGenerator (14)
src\Dependencies\Threading\ProducerConsumer.cs (8)
37await consumeItems(items.ToImmutableAndClear(), args, cancellationToken).ConfigureAwait(false);
77await args.consumeItems(items.ReadAllAsync(cancellationToken), args.args, cancellationToken).ConfigureAwait(false);
114await args.consumeItems(items, args.args, cancellationToken).ConfigureAwait(false);
238await args.produceItems(source, callback, args.args, cancellationToken).ConfigureAwait(false)),
299source, callback, args.args, cancellationToken).ConfigureAwait(false)),
344await Task.WhenAll(writeTask, readTask).ConfigureAwait(false);
367await produceItems(item => channel.Writer.TryWrite(item), args, cancellationToken).ConfigureAwait(false);
384await action(args, cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.Scripting (1)
Microsoft.CodeAnalysis.Test.Utilities (1)
Microsoft.CodeAnalysis.Threading.Package (12)
ProducerConsumer.cs (8)
37await consumeItems(items.ToImmutableAndClear(), args, cancellationToken).ConfigureAwait(false);
77await args.consumeItems(items.ReadAllAsync(cancellationToken), args.args, cancellationToken).ConfigureAwait(false);
114await args.consumeItems(items, args.args, cancellationToken).ConfigureAwait(false);
238await args.produceItems(source, callback, args.args, cancellationToken).ConfigureAwait(false)),
299source, callback, args.args, cancellationToken).ConfigureAwait(false)),
344await Task.WhenAll(writeTask, readTask).ConfigureAwait(false);
367await produceItems(item => channel.Writer.TryWrite(item), args, cancellationToken).ConfigureAwait(false);
384await action(args, cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.Workspaces (173)
Classification\AbstractClassificationService.cs (3)
102document, textSpans, type, options, result, cancellationToken).ConfigureAwait(false);
151document, textSpans, options, getNodeClassifiers, getTokenClassifiers, result, cancellationToken).ConfigureAwait(false);
175document, textSpans, options, result, cancellationToken).ConfigureAwait(false);
Classification\ClassifierHelper.cs (4)
39.ConfigureAwait(false);
78await classificationService.AddSyntacticClassificationsAsync(document, spans, syntaxSpans, cancellationToken).ConfigureAwait(false);
82await classificationService.AddSemanticClassificationsAsync(document, spans, options, semanticSpans, cancellationToken).ConfigureAwait(false);
83await classificationService.AddEmbeddedLanguageClassificationsAsync(document, spans, options, semanticSpans, cancellationToken).ConfigureAwait(false);
FindSymbols\Declarations\DeclarationFinder_AllDeclarations.cs (9)
72await SearchCurrentProjectAsync().ConfigureAwait(false);
73await SearchProjectReferencesAsync().ConfigureAwait(false);
74await SearchMetadataReferencesAsync().ConfigureAwait(false);
86project, query, criteria, buffer, cancellationToken).ConfigureAwait(false);
89await AddAllAsync(buffer, mapSymbol: false).ConfigureAwait(false);
104referencedProject, query, criteria, buffer, cancellationToken).ConfigureAwait(false);
108await AddAllAsync(buffer, mapSymbol: referencedProject.Language != project.Language).ConfigureAwait(false);
129query, criteria, buffer, cancellationToken).ConfigureAwait(false);
132await AddAllAsync(buffer, mapSymbol: false).ConfigureAwait(false);
FindSymbols\FindReferences\DependentTypeFinder.cs (9)
137await DescendInheritanceTreeInProjectAsync(project).ConfigureAwait(false);
155await AddDescendantMetadataTypesInProjectAsync(tempBuffer, project).ConfigureAwait(false);
175await AddDescendantSourceTypesInProjectAsync(tempBuffer, project).ConfigureAwait(false);
220predicate: static n => n.BaseType?.SpecialType == SpecialType.System_Object).ConfigureAwait(false);
224projectIndex.ValueTypes, tempBuffer, predicate: null).ConfigureAwait(false);
228projectIndex.Enums, tempBuffer, predicate: null).ConfigureAwait(false);
232projectIndex.Delegates, tempBuffer, predicate: null).ConfigureAwait(false);
236await AddSourceTypesThatDeriveFromNameAsync(tempBuffer, type.Name).ConfigureAwait(false);
321typesToSearchFor, project, compilation, peReference, tempBuffer).ConfigureAwait(false);
FindSymbols\FindReferences\Finders\ConstructorSymbolReferenceFinder.cs (7)
67project, documents, typeName, processResult, processResultData, cancellationToken).ConfigureAwait(false);
74project, documents, globalAlias, processResult, processResultData, cancellationToken).ConfigureAwait(false);
79project, documents, containingType.SpecialType.ToPredefinedType(), processResult, processResultData, cancellationToken).ConfigureAwait(false);
82project, documents, processResult, processResultData, cancellationToken).ConfigureAwait(false);
87project, documents, processResult, processResultData, cancellationToken).ConfigureAwait(false);
102await FindDocumentsAsync(project, documents, processResult, processResultData, cancellationToken, typeName).ConfigureAwait(false);
105await FindDocumentsAsync(project, documents, processResult, processResultData, cancellationToken, simpleName).ConfigureAwait(false);
FindSymbols\FindReferences\Finders\ExplicitConversionSymbolReferenceFinder.cs (2)
50await FindDocumentsAsync(project, documents, StandardCallbacks<Document>.AddToHashSet, result, cancellationToken, underlyingNamedType.Name).ConfigureAwait(false);
51await FindDocumentsAsync(project, documents, underlyingNamedType.SpecialType.ToPredefinedType(), StandardCallbacks<Document>.AddToHashSet, result, cancellationToken).ConfigureAwait(false);
FindSymbols\FindReferences\Finders\NamedTypeSymbolReferenceFinder.cs (6)
63await AddDocumentsToSearchAsync(symbol.Name, project, documents, processResult, processResultData, cancellationToken).ConfigureAwait(false);
67await AddDocumentsToSearchAsync(alias, project, documents, processResult, processResultData, cancellationToken).ConfigureAwait(false);
71project, documents, symbol.SpecialType.ToPredefinedType(), processResult, processResultData, cancellationToken).ConfigureAwait(false);
74project, documents, processResult, processResultData, cancellationToken).ConfigureAwait(false);
92project, documents, processResult, processResultData, cancellationToken, throughName).ConfigureAwait(false);
95await FindDocumentsAsync(project, documents, processResult, processResultData, cancellationToken, simpleName).ConfigureAwait(false);
FindSymbols\FindReferences\Finders\NamespaceSymbolReferenceFinder.cs (4)
37await FindDocumentsAsync(project, documents, processResult, processResultData, cancellationToken, symbol.Name).ConfigureAwait(false);
39await FindDocumentsWithPredicateAsync(project, documents, static index => index.ContainsGlobalKeyword, processResult, processResultData, cancellationToken).ConfigureAwait(false);
46project, documents, processResult, processResultData, cancellationToken, globalAlias).ConfigureAwait(false);
50await FindDocumentsWithGlobalSuppressMessageAttributeAsync(project, documents, processResult, processResultData, cancellationToken).ConfigureAwait(false);
FindSymbols\FindReferences\Finders\OrdinaryMethodReferenceFinder.cs (7)
72await FindDocumentsAsync(project, documents, processResult, processResultData, cancellationToken, methodSymbol.Name).ConfigureAwait(false);
75await FindDocumentsWithForEachStatementsAsync(project, documents, processResult, processResultData, cancellationToken).ConfigureAwait(false);
78await FindDocumentsWithDeconstructionAsync(project, documents, processResult, processResultData, cancellationToken).ConfigureAwait(false);
81await FindDocumentsWithAwaitExpressionAsync(project, documents, processResult, processResultData, cancellationToken).ConfigureAwait(false);
84project, documents, processResult, processResultData, cancellationToken).ConfigureAwait(false);
87await FindDocumentsWithCollectionInitializersAsync(project, documents, processResult, processResultData, cancellationToken).ConfigureAwait(false);
90await FindDocumentsWithUsingStatementsAsync(project, documents, processResult, processResultData, cancellationToken).ConfigureAwait(false);
FindSymbols\FindReferences\Finders\PropertySymbolReferenceFinder.cs (5)
117await FindDocumentsAsync(project, documents, processResult, processResultData, cancellationToken, symbol.Name).ConfigureAwait(false);
120await FindDocumentsWithForEachStatementsAsync(project, documents, processResult, processResultData, cancellationToken).ConfigureAwait(false);
123await FindDocumentWithExplicitOrImplicitElementAccessExpressionsAsync(project, documents, processResult, processResultData, cancellationToken).ConfigureAwait(false);
126await FindDocumentWithIndexerMemberCrefAsync(project, documents, processResult, processResultData, cancellationToken).ConfigureAwait(false);
128await FindDocumentsWithGlobalSuppressMessageAttributeAsync(project, documents, processResult, processResultData, cancellationToken).ConfigureAwait(false);
FindSymbols\FindReferences\FindReferencesSearchEngine.BidirectionalSymbolSet.cs (2)
58await AddDownSymbolsAsync(this.Engine, current, _allSymbols, workQueue, projects, cancellationToken).ConfigureAwait(false);
59await AddUpSymbolsAsync(this.Engine, current, _allSymbols, workQueue, projects, _includeImplementationsThroughDerivedTypes, cancellationToken).ConfigureAwait(false);
FindSymbols\FindReferences\FindReferencesSearchEngine.cs (7)
74cancellationToken).ConfigureAwait(false);
123tuple.project, tuple.allSymbols, onReferenceFound, cancellationToken).ConfigureAwait(false)).ConfigureAwait(false);
148await symbolSet.InheritanceCascadeAsync(currentProject, cancellationToken).ConfigureAwait(false);
226await AddGlobalAliasesAsync(project, allSymbols, symbolToGlobalAliases, cancellationToken).ConfigureAwait(false);
238_options, cancellationToken).ConfigureAwait(false);
254ProcessDocumentAsync(kvp.Key, kvp.Value, symbolToGlobalAliases, onReferenceFound, cancellationToken)).ConfigureAwait(false);
315}).ConfigureAwait(false);
FindSymbols\FindReferences\FindReferencesSearchEngine.SymbolSet.cs (8)
153await AddCascadedAndLinkedSymbolsToAsync(engine, currentSymbol, result, workQueue, cancellationToken).ConfigureAwait(false);
173engine, currentSymbol, upSymbols, workQueue, allProjects, includeImplementationsThroughDerivedTypes, cancellationToken).ConfigureAwait(false);
183await AddCascadedAndLinkedSymbolsToAsync(engine, symbol, seenSymbols, workQueue, cancellationToken).ConfigureAwait(false);
248await AddCascadedAndLinkedSymbolsToAsync(engine, implementations, seenSymbols, workQueue, cancellationToken).ConfigureAwait(false);
255await AddCascadedAndLinkedSymbolsToAsync(engine, overrides, seenSymbols, workQueue, cancellationToken).ConfigureAwait(false);
285await AddCascadedAndLinkedSymbolsToAsync(engine, match, seenSymbols, workQueue, cancellationToken).ConfigureAwait(false);
290await AddCascadedAndLinkedSymbolsToAsync(engine, overriddenMember, seenSymbols, workQueue, cancellationToken).ConfigureAwait(false);
293await AddCascadedAndLinkedSymbolsToAsync(engine, symbol.ExplicitInterfaceImplementations(), seenSymbols, workQueue, cancellationToken).ConfigureAwait(false);
Rename\ConflictEngine\ConflictResolver.Session.cs (5)
224_cancellationToken).ConfigureAwait(false);
235await DebugVerifyNoErrorsAsync(conflictResolution, documentsIdsToBeCheckedForConflict).ConfigureAwait(false);
296await changeDoc.VerifyNoErrorsAsync("Rename introduced errors in error-free code", _cancellationToken, ignoreErrorCodes).ConfigureAwait(false);
462projectId, renamedSymbolInNewSolution, renameSymbol, referencedSymbols, conflictResolution, reverseMappedLocations, _cancellationToken).ConfigureAwait(false);
702await AddDocumentsWithPotentialConflictsAsync(documentsFromAffectedProjects, documentIds, possibleNameConflicts).ConfigureAwait(false);
src\Dependencies\Threading\ProducerConsumer.cs (8)
37await consumeItems(items.ToImmutableAndClear(), args, cancellationToken).ConfigureAwait(false);
77await args.consumeItems(items.ReadAllAsync(cancellationToken), args.args, cancellationToken).ConfigureAwait(false);
114await args.consumeItems(items, args.args, cancellationToken).ConfigureAwait(false);
238await args.produceItems(source, callback, args.args, cancellationToken).ConfigureAwait(false)),
299source, callback, args.args, cancellationToken).ConfigureAwait(false)),
344await Task.WhenAll(writeTask, readTask).ConfigureAwait(false);
367await produceItems(item => channel.Writer.TryWrite(item), args, cancellationToken).ConfigureAwait(false);
384await action(args, cancellationToken).ConfigureAwait(false);
Workspace\Solution\ChecksumCollection.cs (2)
71await stateChecksums.FindAsync(assetPath, state, searchingChecksumsLeft, onAssetFound, arg, cancellationToken).ConfigureAwait(false);
84await stateChecksums.FindAsync(assetPath, state, searchingChecksumsLeft, onAssetFound, arg, cancellationToken).ConfigureAwait(false);
Workspace\Solution\StateChecksums.cs (8)
130compilationState.FrozenSourceGeneratedDocumentStates, searchingChecksumsLeft, onAssetFound, arg, cancellationToken).ConfigureAwait(false);
175await solutionChecksums.FindAsync(solutionState, projectCone, assetPath, searchingChecksumsLeft, onAssetFound, arg, cancellationToken).ConfigureAwait(false);
181await solutionChecksums.FindAsync(solutionState, projectCone, assetPath, searchingChecksumsLeft, onAssetFound, arg, cancellationToken).ConfigureAwait(false);
298await projectStateChecksums.FindAsync(projectState, assetPath, searchingChecksumsLeft, onAssetFound, arg, cancellationToken).ConfigureAwait(false);
321await projectStateChecksums.FindAsync(projectState, assetPath, searchingChecksumsLeft, onAssetFound, arg, cancellationToken).ConfigureAwait(false);
473await ChecksumCollection.FindAsync(assetPath, state.DocumentStates, searchingChecksumsLeft, onAssetFound, arg, cancellationToken).ConfigureAwait(false);
474await ChecksumCollection.FindAsync(assetPath, state.AdditionalDocumentStates, searchingChecksumsLeft, onAssetFound, arg, cancellationToken).ConfigureAwait(false);
475await ChecksumCollection.FindAsync(assetPath, state.AnalyzerConfigDocumentStates, searchingChecksumsLeft, onAssetFound, arg, cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.Workspaces.MSBuild (5)
Microsoft.CodeAnalysis.Workspaces.MSBuild.BuildHost (7)
Microsoft.CodeAnalysis.Workspaces.MSBuild.UnitTests (4)
Microsoft.CodeAnalysis.Workspaces.Test.Utilities (1)
Microsoft.CommonLanguageServerProtocol.Framework.Package (12)
RequestExecutionQueue.cs (6)
274await InvokeProcessCoreAsync(work, metadata, handler, methodInfo, concurrentlyExecutingTasks, currentWorkCts, cancellationToken).ConfigureAwait(false);
293await _languageServer.ShutdownAsync(message).ConfigureAwait(false);
294await _languageServer.ExitAsync().ConfigureAwait(false);
322await task.ConfigureAwait(false);
369await WrapStartRequestTaskAsync(work.StartRequestAsync<TRequest, TResponse>(deserializedRequest, context, handler, metadata.Language, cancellationToken), rethrowExceptions: true).ConfigureAwait(false);
472await _queue._queueProcessingTask.ConfigureAwait(false);
Microsoft.DotNet.Arcade.Sdk (2)
Microsoft.DotNet.Build.Tasks.Feed (3)
Microsoft.DotNet.Helix.Client (82)
generated-code\Aggregate.cs (22)
220await OnAnalysisSummaryFailed(_req, _res).ConfigureAwait(false);
225await OnAnalysisSummaryFailed(_req, _res).ConfigureAwait(false);
315await OnBuildHistoryFailed(_req, _res).ConfigureAwait(false);
320await OnBuildHistoryFailed(_req, _res).ConfigureAwait(false);
420await OnBuildFailed(_req, _res).ConfigureAwait(false);
425await OnBuildFailed(_req, _res).ConfigureAwait(false);
532await OnJobSummaryFailed(_req, _res).ConfigureAwait(false);
537await OnJobSummaryFailed(_req, _res).ConfigureAwait(false);
639await OnWorkItemSummaryFailed(_req, _res).ConfigureAwait(false);
644await OnWorkItemSummaryFailed(_req, _res).ConfigureAwait(false);
781await OnAnalysisDetailFailed(_req, _res).ConfigureAwait(false);
786await OnAnalysisDetailFailed(_req, _res).ConfigureAwait(false);
875await OnPropertiesFailed(_req, _res).ConfigureAwait(false);
880await OnPropertiesFailed(_req, _res).ConfigureAwait(false);
950await OnInvestigation_ContinueFailed(_req, _res).ConfigureAwait(false);
955await OnInvestigation_ContinueFailed(_req, _res).ConfigureAwait(false);
1067await OnInvestigationFailed(_req, _res).ConfigureAwait(false);
1072await OnInvestigationFailed(_req, _res).ConfigureAwait(false);
1187await OnHistoryFailed(_req, _res).ConfigureAwait(false);
1192await OnHistoryFailed(_req, _res).ConfigureAwait(false);
1268await OnMultiSourceFailed(_req, _res).ConfigureAwait(false);
1273await OnMultiSourceFailed(_req, _res).ConfigureAwait(false);
generated-code\Job.cs (14)
143await OnNewFailed(_req, _res).ConfigureAwait(false);
148await OnNewFailed(_req, _res).ConfigureAwait(false);
242await OnListFailed(_req, _res).ConfigureAwait(false);
247await OnListFailed(_req, _res).ConfigureAwait(false);
317await OnResultsFailed(_req, _res).ConfigureAwait(false);
322await OnResultsFailed(_req, _res).ConfigureAwait(false);
392await OnPassFailFailed(_req, _res).ConfigureAwait(false);
397await OnPassFailFailed(_req, _res).ConfigureAwait(false);
467await OnSummaryFailed(_req, _res).ConfigureAwait(false);
472await OnSummaryFailed(_req, _res).ConfigureAwait(false);
542await OnDetailsFailed(_req, _res).ConfigureAwait(false);
547await OnDetailsFailed(_req, _res).ConfigureAwait(false);
622await OnCancelFailed(_req, _res).ConfigureAwait(false);
688await OnWaitFailed(_req, _res).ConfigureAwait(false);
generated-code\Telemetry.cs (11)
140await OnStartJobFailed(_req, _res).ConfigureAwait(false);
145await OnStartJobFailed(_req, _res).ConfigureAwait(false);
230await OnStartBuildWorkItemFailed(_req, _res).ConfigureAwait(false);
235await OnStartBuildWorkItemFailed(_req, _res).ConfigureAwait(false);
331await OnFinishBuildWorkItemFailed(_req, _res).ConfigureAwait(false);
412await OnStartXUnitWorkItemFailed(_req, _res).ConfigureAwait(false);
417await OnStartXUnitWorkItemFailed(_req, _res).ConfigureAwait(false);
518await OnFinishXUnitWorkItemFailed(_req, _res).ConfigureAwait(false);
615await OnWarningFailed(_req, _res).ConfigureAwait(false);
712await OnErrorFailed(_req, _res).ConfigureAwait(false);
809await OnLogFailed(_req, _res).ConfigureAwait(false);
generated-code\WorkItem.cs (10)
116await OnGetFileFailed(_req, _res).ConfigureAwait(false);
121await OnGetFileFailed(_req, _res).ConfigureAwait(false);
197await OnListFilesFailed(_req, _res).ConfigureAwait(false);
202await OnListFilesFailed(_req, _res).ConfigureAwait(false);
278await OnConsoleLogFailed(_req, _res).ConfigureAwait(false);
283await OnConsoleLogFailed(_req, _res).ConfigureAwait(false);
348await OnListFailed(_req, _res).ConfigureAwait(false);
353await OnListFailed(_req, _res).ConfigureAwait(false);
429await OnDetailsFailed(_req, _res).ConfigureAwait(false);
434await OnDetailsFailed(_req, _res).ConfigureAwait(false);
Microsoft.DotNet.Helix.Sdk (2)
Microsoft.DotNet.Internal.SymbolHelper (3)
Microsoft.Extensions.AI.Abstractions (9)
Microsoft.Extensions.AI.Evaluation (1)
Microsoft.Extensions.AI.Evaluation.Console (4)
Microsoft.Extensions.AI.Evaluation.NLP (1)
Microsoft.Extensions.AI.Evaluation.Quality (1)
Microsoft.Extensions.AI.Evaluation.Reporting (14)
Microsoft.Extensions.AI.Evaluation.Reporting.Azure (5)
Microsoft.Extensions.AI.Evaluation.Safety (2)
Microsoft.Extensions.AI.Templates.Tests (2)
Microsoft.Extensions.Caching.Hybrid (1)
Microsoft.Extensions.Caching.SqlServer (7)
Microsoft.Extensions.Caching.StackExchangeRedis (5)
Microsoft.Extensions.DataIngestion (7)
Microsoft.Extensions.DataIngestion.MarkItDown (3)
Microsoft.Extensions.Diagnostics.HealthChecks (4)
Microsoft.Extensions.Diagnostics.HealthChecks.Tests (1)
Microsoft.Extensions.Diagnostics.Probes (2)
Microsoft.Extensions.Diagnostics.ResourceMonitoring (2)
Microsoft.Extensions.Diagnostics.Testing (1)
Microsoft.Extensions.Hosting (12)
Microsoft.Extensions.Hosting.Abstractions (5)
Microsoft.Extensions.Hosting.Testing (9)
Microsoft.Extensions.Hosting.WindowsServices (1)
Microsoft.Extensions.Http.Diagnostics (2)
Microsoft.Extensions.Http.Diagnostics.Tests (1)
Microsoft.Extensions.Http.Polly.Tests (1)
Microsoft.Extensions.Identity.Core (58)
UserManager.cs (51)
505await UpdateSecurityStampInternal(user).ConfigureAwait(false);
513await GetUserLockoutStore().SetLockoutEnabledAsync(user, true, CancellationToken).ConfigureAwait(false);
515await UpdateNormalizedUserNameAsync(user).ConfigureAwait(false);
516await UpdateNormalizedEmailAsync(user).ConfigureAwait(false);
701await Store.SetNormalizedUserNameAsync(user, normalizedName, CancellationToken).ConfigureAwait(false);
730await Store.SetUserNameAsync(user, userName, CancellationToken).ConfigureAwait(false);
731await UpdateSecurityStampInternal(user).ConfigureAwait(false);
1001await UpdateSecurityStampInternal(user).ConfigureAwait(false);
1098await loginStore.RemoveLoginAsync(user, loginProvider, providerKey, CancellationToken).ConfigureAwait(false);
1099await UpdateSecurityStampInternal(user).ConfigureAwait(false);
1147await loginStore.AddLoginAsync(user, login, CancellationToken).ConfigureAwait(false);
1199await claimStore.AddClaimsAsync(user, claims, CancellationToken).ConfigureAwait(false);
1230await claimStore.ReplaceClaimAsync(user, claim, newClaim, CancellationToken).ConfigureAwait(false);
1273await claimStore.RemoveClaimsAsync(user, claims, CancellationToken).ConfigureAwait(false);
1334await userRoleStore.AddToRoleAsync(user, normalizedRole, CancellationToken).ConfigureAwait(false);
1377await userRoleStore.AddToRoleAsync(user, normalizedRole, CancellationToken).ConfigureAwait(false);
1407await userRoleStore.RemoveFromRoleAsync(user, normalizedRole, CancellationToken).ConfigureAwait(false);
1468await userRoleStore.RemoveFromRoleAsync(user, normalizedRole, CancellationToken).ConfigureAwait(false);
1534await store.SetEmailAsync(user, email, CancellationToken).ConfigureAwait(false);
1535await store.SetEmailConfirmedAsync(user, false, CancellationToken).ConfigureAwait(false);
1536await UpdateSecurityStampInternal(user).ConfigureAwait(false);
1596await store.SetNormalizedEmailAsync(user, ProtectPersonalData(NormalizeEmail(email)!), CancellationToken).ConfigureAwait(false);
1648await store.SetEmailConfirmedAsync(user, true, CancellationToken).ConfigureAwait(false);
1718await store.SetEmailAsync(user, newEmail, CancellationToken).ConfigureAwait(false);
1719await store.SetEmailConfirmedAsync(user, true, CancellationToken).ConfigureAwait(false);
1720await UpdateSecurityStampInternal(user).ConfigureAwait(false);
1755await store.SetPhoneNumberAsync(user, phoneNumber, CancellationToken).ConfigureAwait(false);
1756await store.SetPhoneNumberConfirmedAsync(user, false, CancellationToken).ConfigureAwait(false);
1757await UpdateSecurityStampInternal(user).ConfigureAwait(false);
1805await store.SetPhoneNumberAsync(user, phoneNumber, CancellationToken).ConfigureAwait(false);
1806await store.SetPhoneNumberConfirmedAsync(user, true, CancellationToken).ConfigureAwait(false);
1807await UpdateSecurityStampInternal(user).ConfigureAwait(false);
2073await store.SetTwoFactorEnabledAsync(user, enabled, CancellationToken).ConfigureAwait(false);
2074await UpdateSecurityStampInternal(user).ConfigureAwait(false);
2124await store.SetLockoutEnabledAsync(user, enabled, CancellationToken).ConfigureAwait(false);
2198await store.SetLockoutEndDateAsync(user, lockoutEnd, CancellationToken).ConfigureAwait(false);
2226CancellationToken).ConfigureAwait(false);
2227await store.ResetAccessFailedCountAsync(user, CancellationToken).ConfigureAwait(false);
2268await store.ResetAccessFailedCountAsync(user, CancellationToken).ConfigureAwait(false);
2357await store.SetTokenAsync(user, loginProvider, tokenName, tokenValue, CancellationToken).ConfigureAwait(false);
2385await store.RemoveTokenAsync(user, loginProvider, tokenName, CancellationToken).ConfigureAwait(false);
2421await store.SetAuthenticatorKeyAsync(user, GenerateNewAuthenticatorKey(), CancellationToken).ConfigureAwait(false);
2422await UpdateSecurityStampInternal(user).ConfigureAwait(false);
2460await store.ReplaceCodesAsync(user, newCodes.Distinct(), CancellationToken).ConfigureAwait(false);
2631await passkeyStore.AddOrUpdatePasskeyAsync(user, passkey, CancellationToken).ConfigureAwait(false);
2717await passkeyStore.RemovePasskeyAsync(user, credentialId, CancellationToken).ConfigureAwait(false);
2793await GetSecurityStore().SetSecurityStampAsync(user, NewSecurityStamp(), CancellationToken).ConfigureAwait(false);
2819await passwordStore.SetPasswordHashAsync(user, hash, CancellationToken).ConfigureAwait(false);
2820await UpdateSecurityStampInternal(user).ConfigureAwait(false);
2972await UpdateNormalizedUserNameAsync(user).ConfigureAwait(false);
2973await UpdateNormalizedEmailAsync(user).ConfigureAwait(false);
Microsoft.Extensions.Identity.Stores (3)
Microsoft.Extensions.Logging.AzureAppServices (4)
Microsoft.Extensions.ServiceDiscovery (9)
Microsoft.Extensions.ServiceDiscovery.Dns (1)
Microsoft.Extensions.ServiceDiscovery.Tests (1)
Microsoft.Extensions.TimeProvider.Testing.Tests (1)
Microsoft.Gen.BuildMetadata.Unit.Tests (1)
Microsoft.Gen.ComplianceReports.Unit.Tests (1)
Microsoft.Gen.ContextualOptions.Unit.Tests (1)
Microsoft.Gen.Logging.Unit.Tests (1)
Microsoft.Gen.MetadataExtractor.Unit.Tests (1)
Microsoft.Gen.Metrics.Unit.Tests (1)
Microsoft.Gen.MetricsReports.Unit.Tests (1)
Microsoft.Interop.ComInterfaceGenerator (3)
Microsoft.Interop.LibraryImportGenerator (3)
Microsoft.Maui (2)
Microsoft.Maui.Controls (14)
Microsoft.Maui.Essentials (1)
Microsoft.Maui.Maps (1)
Microsoft.ML.AutoML.Tests (1)
Microsoft.ML.Samples (1)
Microsoft.ML.Samples.GPU (1)
Microsoft.ML.SamplesUtils (1)
Microsoft.ML.Tokenizers.Data.Tests (2)
Microsoft.ML.Tokenizers.Tests (2)
Microsoft.VisualBasic.Forms.Tests (2)
Microsoft.VisualBasic.Tests (1)
Microsoft.VisualStudio.LanguageServices (108)
Library\ObjectBrowser\AbstractDescriptionBuilder.cs (19)
102await AddNamespaceLinkAsync(typeSymbol.ContainingNamespace, cancellationToken).ConfigureAwait(true);
163await BuildMemberOfAsync(namespaceSymbol.ContainingAssembly, cancellationToken).ConfigureAwait(true);
182await BuildDelegateDeclarationAsync(symbol, options, cancellationToken).ConfigureAwait(true);
186await BuildTypeDeclarationAsync(symbol, options, cancellationToken).ConfigureAwait(true);
190await BuildMemberOfAsync(symbol.ContainingNamespace, cancellationToken).ConfigureAwait(true);
191await BuildXmlDocumentationAsync(symbol, compilation, cancellationToken).ConfigureAwait(true);
207await BuildMethodDeclarationAsync((IMethodSymbol)symbol, options, cancellationToken).ConfigureAwait(true);
211await BuildFieldDeclarationAsync((IFieldSymbol)symbol, options, cancellationToken).ConfigureAwait(true);
215await BuildPropertyDeclarationAsync((IPropertySymbol)symbol, options, cancellationToken).ConfigureAwait(true);
219await BuildEventDeclarationAsync((IEventSymbol)symbol, options, cancellationToken).ConfigureAwait(true);
228await BuildMemberOfAsync(symbol.ContainingType, cancellationToken).ConfigureAwait(true);
229await BuildXmlDocumentationAsync(symbol, compilation, cancellationToken).ConfigureAwait(true);
271typeSymbol, LinkFlags.SplitNamespaceAndType | LinkFlags.ExpandPredefinedTypes, cancellationToken).ConfigureAwait(true);
275await AddNamespaceLinkAsync(namespaceSymbol, cancellationToken).ConfigureAwait(true);
425await AddTypeLinkAsync(exceptionTypeSymbol, LinkFlags.None, cancellationToken).ConfigureAwait(true);
431await AddTypeLinkAsync(exceptionTypeSymbol, LinkFlags.None, cancellationToken).ConfigureAwait(true);
466await BuildNamespaceAsync(namespaceListItem, options, cancellationToken).ConfigureAwait(true);
469await BuildTypeAsync(typeListItem, options, cancellationToken).ConfigureAwait(true);
472await BuildMemberAsync(memberListItem, options, cancellationToken).ConfigureAwait(true);
Packaging\PackageInstallerServiceFactory.cs (7)
308await UpdateStatusBarAsync(dte, description, cancellationToken).ConfigureAwait(false);
339cancellationToken).ConfigureAwait(false);
346await UpdateStatusBarAsync(dte, ServicesVSResources.Package_install_canceled, cancellationToken).ConfigureAwait(false);
380await UpdateStatusBarAsync(dte, description, cancellationToken).ConfigureAwait(false);
400dte, string.Format(ServicesVSResources.Uninstalling_0_completed, GetStatusBarText(packageName, installedVersion)), cancellationToken).ConfigureAwait(false);
407await UpdateStatusBarAsync(dte, ServicesVSResources.Package_uninstall_canceled, cancellationToken).ConfigureAwait(false);
488await ProcessProjectChangeAsync(nugetService, solution, projectId, cancellationToken).ConfigureAwait(false);
Microsoft.VisualStudio.LanguageServices.CodeLens (2)
Microsoft.VisualStudio.LanguageServices.CSharp (24)
ObjectBrowser\DescriptionBuilder.cs (18)
40await AddTypeLinkAsync(delegateInvokeMethod.ReturnType, LinkFlags.None, cancellationToken).ConfigureAwait(true);
54await BuildParameterListAsync(delegateInvokeMethod.Parameters, cancellationToken).ConfigureAwait(true);
58await BuildGenericConstraintsAsync(typeSymbol, cancellationToken).ConfigureAwait(true);
102await AddTypeLinkAsync(underlyingType, LinkFlags.None, cancellationToken).ConfigureAwait(true);
118await AddTypeLinkAsync(baseType, LinkFlags.None, cancellationToken).ConfigureAwait(true);
124await BuildGenericConstraintsAsync(typeSymbol, cancellationToken).ConfigureAwait(true);
195await AddTypeLinkAsync(methodSymbol.ReturnType, LinkFlags.None, cancellationToken).ConfigureAwait(true);
212await AddTypeLinkAsync(methodSymbol.ReturnType, LinkFlags.None, cancellationToken).ConfigureAwait(true);
229await BuildParameterListAsync(methodSymbol.Parameters, cancellationToken).ConfigureAwait(true);
233await BuildGenericConstraintsAsync(methodSymbol, cancellationToken).ConfigureAwait(true);
321await BuildConstraintsAsync(typeParameterSymbol, cancellationToken).ConfigureAwait(true);
327await BuildConstraintsAsync(typeParameterSymbol, cancellationToken).ConfigureAwait(true);
378await AddTypeLinkAsync(constraintType, LinkFlags.None, cancellationToken).ConfigureAwait(true);
441await AddTypeLinkAsync(current.Type, LinkFlags.None, cancellationToken).ConfigureAwait(true);
472await AddTypeLinkAsync(fieldSymbol.Type, LinkFlags.None, cancellationToken).ConfigureAwait(true);
484await AddTypeLinkAsync(propertySymbol.Type, LinkFlags.None, cancellationToken).ConfigureAwait(true);
491await BuildParameterListAsync(propertySymbol.Parameters, cancellationToken).ConfigureAwait(true);
531await AddTypeLinkAsync(eventSymbol.Type, LinkFlags.None, cancellationToken).ConfigureAwait(true);
Microsoft.VisualStudio.LanguageServices.Implementation (7)
Microsoft.VisualStudio.LanguageServices.LiveShare (6)
Microsoft.VisualStudio.LanguageServices.Xaml (1)
Pipelines.AppHost (16)
Pipelines.Library (9)
Replay (11)
src\Compilers\Shared\BuildProtocol.cs (7)
128await ReadAllAsync(inStream, lengthBuffer, 4, cancellationToken).ConfigureAwait(false);
187cancellationToken).ConfigureAwait(false);
190await memoryStream.CopyToAsync(outStream, bufferSize: length, cancellationToken: cancellationToken).ConfigureAwait(false);
305cancellationToken).ConfigureAwait(false);
308await memoryStream.CopyToAsync(outStream, bufferSize: length, cancellationToken: cancellationToken).ConfigureAwait(false);
324await ReadAllAsync(stream, lengthBuffer, 4, cancellationToken).ConfigureAwait(false);
332cancellationToken).ConfigureAwait(false);
Roslyn.Compilers.Extension (2)
Roslyn.Diagnostics.Analyzers (20)
src\Dependencies\Threading\ProducerConsumer.cs (8)
37await consumeItems(items.ToImmutableAndClear(), args, cancellationToken).ConfigureAwait(false);
77await args.consumeItems(items.ReadAllAsync(cancellationToken), args.args, cancellationToken).ConfigureAwait(false);
114await args.consumeItems(items, args.args, cancellationToken).ConfigureAwait(false);
238await args.produceItems(source, callback, args.args, cancellationToken).ConfigureAwait(false)),
299source, callback, args.args, cancellationToken).ConfigureAwait(false)),
344await Task.WhenAll(writeTask, readTask).ConfigureAwait(false);
367await produceItems(item => channel.Writer.TryWrite(item), args, cancellationToken).ConfigureAwait(false);
384await action(args, cancellationToken).ConfigureAwait(false);
Roslyn.Diagnostics.CSharp.Analyzers (2)
Roslyn.VisualStudio.DiagnosticsWindow (4)
Roslyn.VisualStudio.Next.UnitTests (23)
Remote\SerializationValidator.cs (20)
133await VerifyAssetAsync(projectObject).ConfigureAwait(false);
173await VerifyAssetAsync(attributeChecksum, textChecksum).ConfigureAwait(false);
176await VerifyAssetAsync(attributeChecksum, textChecksum).ConfigureAwait(false);
179await VerifyAssetAsync(attributeChecksum, textChecksum).ConfigureAwait(false);
289await VerifyChecksumInServiceAsync(projectObject.Checksum, projectObject.GetWellKnownSynchronizationKind()).ConfigureAwait(false);
290await VerifyChecksumInServiceAsync(projectObject.Info, WellKnownSynchronizationKind.ProjectAttributes).ConfigureAwait(false);
291await VerifyChecksumInServiceAsync(projectObject.CompilationOptions, WellKnownSynchronizationKind.CompilationOptions).ConfigureAwait(false);
292await VerifyChecksumInServiceAsync(projectObject.ParseOptions, WellKnownSynchronizationKind.ParseOptions).ConfigureAwait(false);
296await VerifyCollectionInService(projectObject.ProjectReferences, expectedProjectReferenceCount, WellKnownSynchronizationKind.ProjectReference).ConfigureAwait(false);
297await VerifyCollectionInService(projectObject.MetadataReferences, expectedMetadataReferenceCount, WellKnownSynchronizationKind.MetadataReference).ConfigureAwait(false);
298await VerifyCollectionInService(projectObject.AnalyzerReferences, expectedAnalyzerReferenceCount, WellKnownSynchronizationKind.AnalyzerReference).ConfigureAwait(false);
305await VerifyChecksumInServiceAsync(checksums.Checksum, checksums.GetWellKnownSynchronizationKind()).ConfigureAwait(false);
310await VerifyChecksumInServiceAsync(checksum, expectedItemKind).ConfigureAwait(false);
316await VerifySynchronizationObjectInServiceAsync(documents).ConfigureAwait(false);
321await VerifySnapshotInServiceAsync(documentId).ConfigureAwait(false);
327await VerifyChecksumInServiceAsync(documentObject.Checksum, documentObject.GetWellKnownSynchronizationKind()).ConfigureAwait(false);
328await VerifyChecksumInServiceAsync(documentObject.Info, WellKnownSynchronizationKind.DocumentAttributes).ConfigureAwait(false);
329await VerifyChecksumInServiceAsync(documentObject.Text, WellKnownSynchronizationKind.SerializableSourceText).ConfigureAwait(false);
333=> await VerifyChecksumInServiceAsync(syncObject.Checksum, syncObject.Kind).ConfigureAwait(false);
336=> await VerifyChecksumInServiceAsync(syncObject.Checksum, syncObject.Kind).ConfigureAwait(false);
Shared (1)
Sockets.BindTests (8)
Sockets.FunctionalTests (11)
Stress.AppHost (1)
System.Data.Common (13)
System.Diagnostics.Process (5)
System.DirectoryServices.Protocols (1)
System.Formats.Tar (21)
System.IO.Compression (25)
System\IO\Compression\ZipArchive.Async.cs (12)
82await backingStream.CopyToAsync(stream, cancellationToken).ConfigureAwait(false);
94await zipArchive.ReadEndOfCentralDirectoryAsync(cancellationToken).ConfigureAwait(false);
105await zipArchive.ReadEndOfCentralDirectoryAsync(cancellationToken).ConfigureAwait(false);
106await zipArchive.EnsureCentralDirectoryReadAsync(cancellationToken).ConfigureAwait(false);
110await entry.ThrowIfNotOpenableAsync(needToUncompress: false, needToLoadIntoMemory: true, cancellationToken).ConfigureAwait(false);
155await CloseStreamsAsync().ConfigureAwait(false);
189await ReadCentralDirectoryAsync(cancellationToken).ConfigureAwait(false);
359await entry.LoadLocalHeaderExtraFieldIfNeededAsync(cancellationToken).ConfigureAwait(false);
362await entry.LoadCompressedBytesIfNeededAsync(cancellationToken).ConfigureAwait(false);
380await entry.WriteAndFinishLocalEntryAsync(forceWriteLocalEntry, cancellationToken).ConfigureAwait(false);
393await entry.WriteCentralDirectoryFileHeaderAsync(centralDirectoryEntryRequiresUpdate, cancellationToken).ConfigureAwait(false);
436await ZipEndOfCentralDirectoryBlock.WriteBlockAsync(_archiveStream, _entries.Count, startOfCentralDirectory, sizeOfCentralDirectory, _archiveComment, cancellationToken).ConfigureAwait(false);
System\IO\Compression\ZipArchiveEntry.Async.cs (9)
73await decompressor.CopyToAsync(_storedUncompressedData, cancellationToken).ConfigureAwait(false);
113await CloseStreamsAsync().ConfigureAwait(false);
114await WriteLocalFileHeaderAndDataIfNeededAsync(forceWrite, cancellationToken).ConfigureAwait(false);
115await UnloadStreamsAsync().ConfigureAwait(false);
138await ZipGenericExtraField.WriteAllBlocksAsync(_cdUnknownExtraFields, _cdTrailingExtraFieldData ?? Array.Empty<byte>(), _archive.ArchiveStream, cancellationToken).ConfigureAwait(false);
200await ThrowIfNotOpenableAsync(needToUncompress: true, needToLoadIntoMemory: false, cancellationToken).ConfigureAwait(false);
212await ThrowIfNotOpenableAsync(needToUncompress: true, needToLoadIntoMemory: true, cancellationToken).ConfigureAwait(false);
280await ZipGenericExtraField.WriteAllBlocksAsync(_lhUnknownExtraFields, _lhTrailingExtraFieldData ?? Array.Empty<byte>(), _archive.ArchiveStream, cancellationToken).ConfigureAwait(false);
302await _storedUncompressedData.CopyToAsync(entryWriter, cancellationToken).ConfigureAwait(false);
System.IO.Compression.Brotli (1)
System.IO.Compression.ZipFile (8)
System.IO.Pipelines (3)
System.Memory.Data (1)
System.Net.Http (37)
System.Net.Http.Json (1)
System.Net.HttpListener (3)
System.Net.Mail (19)
System.Net.Ping (1)
System.Net.Quic (3)
System.Net.Requests (3)
System.Net.Security (19)
System\Net\Security\NegotiateStream.cs (8)
736SendBlobAsync<TIOAdapter>(message: null, cancellationToken)).ConfigureAwait(false); // client should send the first blob
781await SendAuthResetSignalAndThrowAsync<TIOAdapter>(message, exception, cancellationToken).ConfigureAwait(false);
805await _framer!.WriteMessageAsync<TIOAdapter>(InnerStream, message, cancellationToken).ConfigureAwait(false);
842await SendAuthResetSignalAndThrowAsync<TIOAdapter>(message!, exception, cancellationToken).ConfigureAwait(false);
852await _framer!.WriteMessageAsync<TIOAdapter>(InnerStream, message, cancellationToken).ConfigureAwait(false);
855await ReceiveBlobAsync<TIOAdapter>(cancellationToken).ConfigureAwait(false);
914await SendBlobAsync<TIOAdapter>(message, cancellationToken).ConfigureAwait(false);
924await _framer.WriteMessageAsync<TIOAdapter>(InnerStream, message, cancellationToken).ConfigureAwait(false);
System.Net.Sockets (1)
System.Net.WebSockets (8)
System.Net.WebSockets.Client (1)
System.Private.CoreLib (82)
System.Private.DataContractSerialization (29)
System\Xml\XmlBaseWriter.cs (14)
377await FlushBase64Async().ConfigureAwait(false);
419await _writer.WriteEndAttributeAsync().ConfigureAwait(false);
548await _writer.WriteStartElementAsync(prefix, localName).ConfigureAwait(false);
553await FlushBase64Async().ConfigureAwait(false);
554await AutoCompleteAsync(WriteState.Element).ConfigureAwait(false);
644await WriteEndAttributeAsync().ConfigureAwait(false);
650await _writer.WriteEndStartElementAsync(true).ConfigureAwait(false);
655await _writer.WriteEndElementAsync(element.Prefix, element.LocalName!).ConfigureAwait(false);
725await FlushElementAsync().ConfigureAwait(false);
786await EndStartElementAsync().ConfigureAwait(false);
1549await StartContentAsync().ConfigureAwait(false);
1550await _writer.WriteBase64TextAsync(_trailBytes, _trailByteCount, buffer, offset, actualByteCount - _trailByteCount).ConfigureAwait(false);
1768await StartContentAsync().ConfigureAwait(false);
1769await _writer.WriteBase64TextAsync(_trailBytes, _trailByteCount, _trailBytes, 0, 0).ConfigureAwait(false);
System.Private.Xml (407)
System\Xml\Core\XmlEncodedRawTextWriterAsync.cs (82)
40await RawTextAsync("<?xml version=\"").ConfigureAwait(false);
43await RawTextAsync("1.0").ConfigureAwait(false);
48await RawTextAsync("\" encoding=\"").ConfigureAwait(false);
49await RawTextAsync(_encoding.WebName).ConfigureAwait(false);
55await RawTextAsync("\" standalone=\"").ConfigureAwait(false);
56await RawTextAsync(standalone == XmlStandalone.Yes ? "yes" : "no").ConfigureAwait(false);
59await RawTextAsync("\"?>").ConfigureAwait(false);
79await FlushBufferAsync().ConfigureAwait(false);
90await _stream.FlushAsync().ConfigureAwait(false);
111await _writer.FlushAsync().ConfigureAwait(false);
139await RawTextAsync("<!DOCTYPE ").ConfigureAwait(false);
140await RawTextAsync(name).ConfigureAwait(false);
143await RawTextAsync(" PUBLIC \"").ConfigureAwait(false);
144await RawTextAsync(pubid).ConfigureAwait(false);
145await RawTextAsync("\" \"").ConfigureAwait(false);
148await RawTextAsync(sysid).ConfigureAwait(false);
154await RawTextAsync(" SYSTEM \"").ConfigureAwait(false);
155await RawTextAsync(sysid).ConfigureAwait(false);
166await RawTextAsync(subset).ConfigureAwait(false);
309await WriteStartNamespaceDeclarationAsync(prefix).ConfigureAwait(false);
310await WriteStringAsync(namespaceName).ConfigureAwait(false);
311await WriteEndNamespaceDeclarationAsync().ConfigureAwait(false);
328await RawTextAsync("xmlns=\"").ConfigureAwait(false);
332await RawTextAsync("xmlns:").ConfigureAwait(false);
333await RawTextAsync(prefix).ConfigureAwait(false);
386await WriteCDataSectionAsync(text).ConfigureAwait(false);
409await WriteCommentOrPiAsync(text, '-').ConfigureAwait(false);
427await RawTextAsync(name).ConfigureAwait(false);
432await WriteCommentOrPiAsync(text, '?').ConfigureAwait(false);
448await RawTextAsync(name).ConfigureAwait(false);
453await FlushBufferAsync().ConfigureAwait(false);
476await RawTextAsync(strVal).ConfigureAwait(false);
481await FlushBufferAsync().ConfigureAwait(false);
537await RawTextAsync(surrogateChar.ToString("X", NumberFormatInfo.InvariantInfo)).ConfigureAwait(false);
576await WriteRawWithCharCheckingAsync(buffer, index, count).ConfigureAwait(false);
590await WriteRawWithCharCheckingAsync(data).ConfigureAwait(false);
599await FlushBufferAsync().ConfigureAwait(false);
600await FlushEncoderAsync().ConfigureAwait(false);
604await _stream.FlushAsync().ConfigureAwait(false);
608await _writer.FlushAsync().ConfigureAwait(false);
645await EncodeCharsAsync(1, _bufPos, true).ConfigureAwait(false);
652await _writer!.WriteAsync(_bufChars.AsMemory(1, _bufPos - 1)).ConfigureAwait(false);
884await FlushBufferAsync().ConfigureAwait(false);
909await FlushBufferAsync().ConfigureAwait(false);
917await FlushBufferAsync().ConfigureAwait(false);
1097await RawTextAsync(_newLineChars).ConfigureAwait(false);
1103await FlushBufferAsync().ConfigureAwait(false);
1137await RawTextAsync(_newLineChars).ConfigureAwait(false);
1143await FlushBufferAsync().ConfigureAwait(false);
1154await RawTextAsync(_newLineChars).ConfigureAwait(false);
1160await FlushBufferAsync().ConfigureAwait(false);
1319await FlushBufferAsync().ConfigureAwait(false);
1328await FlushBufferAsync().ConfigureAwait(false);
1335await RawTextAsync(text2, text3, text4).ConfigureAwait(false);
1495await RawTextAsync(_newLineChars).ConfigureAwait(false);
1501await FlushBufferAsync().ConfigureAwait(false);
1519await RawTextAsync(_newLineChars).ConfigureAwait(false);
1525await FlushBufferAsync().ConfigureAwait(false);
1690await FlushBufferAsync().ConfigureAwait(false);
1706await RawTextAsync(_newLineChars).ConfigureAwait(false);
1712await FlushBufferAsync().ConfigureAwait(false);
1874await FlushBufferAsync().ConfigureAwait(false);
1890await RawTextAsync(_newLineChars).ConfigureAwait(false);
1896await FlushBufferAsync().ConfigureAwait(false);
1911await WriteIndentAsync().ConfigureAwait(false);
1913await base.WriteDocTypeAsync(name, pubid, sysid, subset).ConfigureAwait(false);
1924await WriteIndentAsync().ConfigureAwait(false);
1929await base.WriteStartElementAsync(prefix, localName, ns).ConfigureAwait(false);
1942await WriteIndentAsync().ConfigureAwait(false);
1947await base.WriteEndElementAsync(prefix, localName, ns).ConfigureAwait(false);
1960await WriteIndentAsync().ConfigureAwait(false);
1965await base.WriteFullEndElementAsync(prefix, localName, ns).ConfigureAwait(false);
1975await WriteIndentAsync().ConfigureAwait(false);
1978await base.WriteStartAttributeAsync(prefix, localName, ns).ConfigureAwait(false);
1988await WriteIndentAsync().ConfigureAwait(false);
1991await base.WriteStartNamespaceDeclarationAsync(prefix).ConfigureAwait(false);
2006await WriteIndentAsync().ConfigureAwait(false);
2009await base.WriteCommentAsync(text).ConfigureAwait(false);
2017await WriteIndentAsync().ConfigureAwait(false);
2020await base.WriteProcessingInstructionAsync(target, text).ConfigureAwait(false);
2090await RawTextAsync(base._newLineChars).ConfigureAwait(false);
2093await RawTextAsync(_indentChars).ConfigureAwait(false);
System\Xml\Core\XmlTextReaderImplAsync.cs (39)
46await FinishPartialValueAsync().ConfigureAwait(false);
51await FinishOtherValueIteratorAsync().ConfigureAwait(false);
95await InitStreamInputAsync(_laterInitParam.inputbaseUri, _reportedBaseUri, stream, null, 0, enc).ConfigureAwait(false);
102await ProcessDtdFromParserContextAsync(_laterInitParam.inputContext).ConfigureAwait(false);
126await InitStreamInputAsync(_laterInitParam.inputbaseUri, _reportedBaseUri, _laterInitParam!.inputStream!, _laterInitParam.inputBytes, _laterInitParam.inputByteCount, enc).ConfigureAwait(false);
133await ProcessDtdFromParserContextAsync(_laterInitParam.inputContext).ConfigureAwait(false);
148await ProcessDtdFromParserContextAsync(_laterInitParam.inputContext).ConfigureAwait(false);
330await SkipPartialTextValueAsync().ConfigureAwait(false);
333await FinishReadValueChunkAsync().ConfigureAwait(false);
336await FinishReadContentAsBinaryAsync().ConfigureAwait(false);
339await FinishReadElementContentAsBinaryAsync().ConfigureAwait(false);
770await ParseCDataOrCommentAsync(XmlNodeType.Comment).ConfigureAwait(false);
778await ParseCDataOrCommentAsync(XmlNodeType.Comment).ConfigureAwait(false);
841await PushExternalEntityOrSubsetAsync(publicId, systemId, _ps.baseUri, null).ConfigureAwait(false);
1247await SwitchEncodingToUTF8Async().ConfigureAwait(false);
1252await SwitchEncodingAsync(encoding).ConfigureAwait(false);
1460await SwitchEncodingToUTF8Async().ConfigureAwait(false);
1636await ParseEntityReferenceAsync().ConfigureAwait(false);
1946await ParseElementAsync_SetElement(colonPos, pos).ConfigureAwait(false);
2057await ParseElementAsync_NoAttributes().ConfigureAwait(false);
2077await ParseEndElmentAsync_PrepareData().ConfigureAwait(false);
2078await ParseEndElementAsync_CheckNameAndParse().ConfigureAwait(false);
2166await task.ConfigureAwait(false);
2539await ParseAttributeValueSlowAsync(pos, quoteChar, attr).ConfigureAwait(false);
3570await FinishPartialValueAsync().ConfigureAwait(false);
3587await FinishPartialValueAsync().ConfigureAwait(false);
3650await SkipPartialTextValueAsync().ConfigureAwait(false);
3665await FinishReadContentAsBinaryAsync().ConfigureAwait(false);
3815await ParseDtdFromParserContextAsync().ConfigureAwait(false);
4178await ParseCDataOrCommentAsync(XmlNodeType.Comment).ConfigureAwait(false);
4184await ParseCDataOrCommentAsync(XmlNodeType.Comment).ConfigureAwait(false);
4451await ParseDtdAsync().ConfigureAwait(false);
4462await SkipDtdAsync().ConfigureAwait(false);
4521await SkipPublicOrSystemIdLiteralAsync().ConfigureAwait(false);
4530await SkipPublicOrSystemIdLiteralAsync().ConfigureAwait(false);
4558await SkipPublicOrSystemIdLiteralAsync().ConfigureAwait(false);
4572await SkipUntilAsync(']', true).ConfigureAwait(false);
5187await InitStreamInputAsync(uri, stream, null).ConfigureAwait(false);
5207await PushExternalEntityOrSubsetAsync(entity.PublicId, entity.SystemId, entityBaseUri, entity.Name).ConfigureAwait(false);
System\Xml\Core\XmlUtf8RawTextWriterAsync.cs (77)
39await RawTextAsync("<?xml version=\"").ConfigureAwait(false);
42await RawTextAsync("1.0").ConfigureAwait(false);
47await RawTextAsync("\" encoding=\"").ConfigureAwait(false);
48await RawTextAsync(_encoding.WebName).ConfigureAwait(false);
54await RawTextAsync("\" standalone=\"").ConfigureAwait(false);
55await RawTextAsync(standalone == XmlStandalone.Yes ? "yes" : "no").ConfigureAwait(false);
58await RawTextAsync("\"?>").ConfigureAwait(false);
78await FlushBufferAsync().ConfigureAwait(false);
89await _stream.FlushAsync().ConfigureAwait(false);
115await RawTextAsync("<!DOCTYPE ").ConfigureAwait(false);
116await RawTextAsync(name).ConfigureAwait(false);
119await RawTextAsync(" PUBLIC \"").ConfigureAwait(false);
120await RawTextAsync(pubid).ConfigureAwait(false);
121await RawTextAsync("\" \"").ConfigureAwait(false);
124await RawTextAsync(sysid).ConfigureAwait(false);
130await RawTextAsync(" SYSTEM \"").ConfigureAwait(false);
131await RawTextAsync(sysid).ConfigureAwait(false);
142await RawTextAsync(subset).ConfigureAwait(false);
275await WriteStartNamespaceDeclarationAsync(prefix).ConfigureAwait(false);
276await WriteStringAsync(namespaceName).ConfigureAwait(false);
277await WriteEndNamespaceDeclarationAsync().ConfigureAwait(false);
292await RawTextAsync("xmlns=\"").ConfigureAwait(false);
296await RawTextAsync("xmlns:").ConfigureAwait(false);
297await RawTextAsync(prefix).ConfigureAwait(false);
344await WriteCDataSectionAsync(text).ConfigureAwait(false);
365await WriteCommentOrPiAsync(text, '-').ConfigureAwait(false);
381await RawTextAsync(name).ConfigureAwait(false);
386await WriteCommentOrPiAsync(text, '?').ConfigureAwait(false);
400await RawTextAsync(name).ConfigureAwait(false);
405await FlushBufferAsync().ConfigureAwait(false);
426await RawTextAsync(strVal).ConfigureAwait(false);
431await FlushBufferAsync().ConfigureAwait(false);
481await RawTextAsync(surrogateChar.ToString("X", NumberFormatInfo.InvariantInfo)).ConfigureAwait(false);
516await WriteRawWithCharCheckingAsync(buffer, index, count).ConfigureAwait(false);
528await WriteRawWithCharCheckingAsync(data).ConfigureAwait(false);
537await FlushBufferAsync().ConfigureAwait(false);
541await _stream.FlushAsync().ConfigureAwait(false);
757await FlushBufferAsync().ConfigureAwait(false);
782await FlushBufferAsync().ConfigureAwait(false);
790await FlushBufferAsync().ConfigureAwait(false);
969await RawTextAsync(_newLineChars).ConfigureAwait(false);
975await FlushBufferAsync().ConfigureAwait(false);
1009await RawTextAsync(_newLineChars).ConfigureAwait(false);
1015await FlushBufferAsync().ConfigureAwait(false);
1026await RawTextAsync(_newLineChars).ConfigureAwait(false);
1032await FlushBufferAsync().ConfigureAwait(false);
1190await FlushBufferAsync().ConfigureAwait(false);
1199await FlushBufferAsync().ConfigureAwait(false);
1206await RawTextAsync(text2, text3, text4).ConfigureAwait(false);
1365await RawTextAsync(_newLineChars).ConfigureAwait(false);
1371await FlushBufferAsync().ConfigureAwait(false);
1389await RawTextAsync(_newLineChars).ConfigureAwait(false);
1395await FlushBufferAsync().ConfigureAwait(false);
1559await FlushBufferAsync().ConfigureAwait(false);
1575await RawTextAsync(_newLineChars).ConfigureAwait(false);
1581await FlushBufferAsync().ConfigureAwait(false);
1742await FlushBufferAsync().ConfigureAwait(false);
1758await RawTextAsync(_newLineChars).ConfigureAwait(false);
1764await FlushBufferAsync().ConfigureAwait(false);
1779await WriteIndentAsync().ConfigureAwait(false);
1781await base.WriteDocTypeAsync(name, pubid, sysid, subset).ConfigureAwait(false);
1792await WriteIndentAsync().ConfigureAwait(false);
1797await base.WriteStartElementAsync(prefix, localName, ns).ConfigureAwait(false);
1810await WriteIndentAsync().ConfigureAwait(false);
1815await base.WriteEndElementAsync(prefix, localName, ns).ConfigureAwait(false);
1828await WriteIndentAsync().ConfigureAwait(false);
1833await base.WriteFullEndElementAsync(prefix, localName, ns).ConfigureAwait(false);
1843await WriteIndentAsync().ConfigureAwait(false);
1846await base.WriteStartAttributeAsync(prefix, localName, ns).ConfigureAwait(false);
1856await WriteIndentAsync().ConfigureAwait(false);
1859await base.WriteStartNamespaceDeclarationAsync(prefix).ConfigureAwait(false);
1874await WriteIndentAsync().ConfigureAwait(false);
1877await base.WriteCommentAsync(text).ConfigureAwait(false);
1885await WriteIndentAsync().ConfigureAwait(false);
1888await base.WriteProcessingInstructionAsync(target, text).ConfigureAwait(false);
1958await RawTextAsync(base._newLineChars).ConfigureAwait(false);
1961await RawTextAsync(_indentChars).ConfigureAwait(false);
System\Xml\Core\XmlWellFormedWriterAsync.cs (79)
38await WriteEndElementAsync().ConfigureAwait(false);
41await AdvanceStateAsync(Token.EndDocument).ConfigureAwait(false);
49await _writer.WriteEndDocumentAsync().ConfigureAwait(false);
72await AdvanceStateAsync(Token.Dtd).ConfigureAwait(false);
114await _writer.WriteDocTypeAsync(name, pubid, sysid, subset).ConfigureAwait(false);
141await task.ConfigureAwait(false);
167await task.ConfigureAwait(false);
168await nextTaskFun(arg).ConfigureAwait(false);
263await task.ConfigureAwait(false);
264await WriteStartElementAsync_NoAdvanceState(prefix, localName, ns).ConfigureAwait(false);
306await t.ConfigureAwait(false);
598await task.ConfigureAwait(false);
599await WriteStartAttributeAsync_NoAdvanceState(prefix, localName, namespaceName).ConfigureAwait(false);
660await _rawWriter.WriteStartNamespaceDeclarationAsync(string.Empty).ConfigureAwait(false);
661await _attrValueCache.ReplayAsync(_rawWriter).ConfigureAwait(false);
662await _rawWriter.WriteEndNamespaceDeclarationAsync().ConfigureAwait(false);
666await _rawWriter.WriteNamespaceDeclarationAsync(string.Empty, value).ConfigureAwait(false);
671await _writer.WriteStartAttributeAsync(string.Empty, "xmlns", XmlReservedNs.NsXmlNs).ConfigureAwait(false);
672await _attrValueCache.ReplayAsync(_writer).ConfigureAwait(false);
673await _writer.WriteEndAttributeAsync().ConfigureAwait(false);
697await _rawWriter.WriteStartNamespaceDeclarationAsync(_curDeclPrefix).ConfigureAwait(false);
698await _attrValueCache.ReplayAsync(_rawWriter).ConfigureAwait(false);
699await _rawWriter.WriteEndNamespaceDeclarationAsync().ConfigureAwait(false);
703await _rawWriter.WriteNamespaceDeclarationAsync(_curDeclPrefix, value).ConfigureAwait(false);
708await _writer.WriteStartAttributeAsync("xmlns", _curDeclPrefix, XmlReservedNs.NsXmlNs).ConfigureAwait(false);
709await _attrValueCache.ReplayAsync(_writer).ConfigureAwait(false);
710await _writer.WriteEndAttributeAsync().ConfigureAwait(false);
731await _writer.WriteStartAttributeAsync("xml", "space", XmlReservedNs.NsXml).ConfigureAwait(false);
732await _attrValueCache.ReplayAsync(_writer).ConfigureAwait(false);
733await _writer.WriteEndAttributeAsync().ConfigureAwait(false);
738await _writer.WriteStartAttributeAsync("xml", "lang", XmlReservedNs.NsXml).ConfigureAwait(false);
739await _attrValueCache.ReplayAsync(_writer).ConfigureAwait(false);
740await _writer.WriteEndAttributeAsync().ConfigureAwait(false);
759await AdvanceStateAsync(Token.CData).ConfigureAwait(false);
760await _writer.WriteCDataAsync(text).ConfigureAwait(false);
775await AdvanceStateAsync(Token.Comment).ConfigureAwait(false);
776await _writer.WriteCommentAsync(text).ConfigureAwait(false);
805await AdvanceStateAsync(Token.PI).ConfigureAwait(false);
810await _rawWriter.WriteXmlDeclarationAsync(text).ConfigureAwait(false);
814await _writer.WriteProcessingInstructionAsync(name, text).ConfigureAwait(false);
819await AdvanceStateAsync(Token.PI).ConfigureAwait(false);
820await _writer.WriteProcessingInstructionAsync(name, text).ConfigureAwait(false);
838await AdvanceStateAsync(Token.Text).ConfigureAwait(false);
845await _writer.WriteEntityRefAsync(name).ConfigureAwait(false);
864await AdvanceStateAsync(Token.Text).ConfigureAwait(false);
871await _writer.WriteCharEntityAsync(ch).ConfigureAwait(false);
890await AdvanceStateAsync(Token.Text).ConfigureAwait(false);
897await _writer.WriteSurrogateCharEntityAsync(lowChar, highChar).ConfigureAwait(false);
918await AdvanceStateAsync(Token.Whitespace).ConfigureAwait(false);
925await _writer.WriteWhitespaceAsync(ws).ConfigureAwait(false);
987await task.ConfigureAwait(false);
988await WriteStringAsync_NoAdvanceState(text).ConfigureAwait(false);
1006await AdvanceStateAsync(Token.Text).ConfigureAwait(false);
1013await _writer.WriteCharsAsync(buffer, index, count).ConfigureAwait(false);
1032await AdvanceStateAsync(Token.RawData).ConfigureAwait(false);
1039await _writer.WriteRawAsync(buffer, index, count).ConfigureAwait(false);
1058await AdvanceStateAsync(Token.RawData).ConfigureAwait(false);
1065await _writer.WriteRawAsync(data).ConfigureAwait(false);
1106await task.ConfigureAwait(false);
1107await _writer.WriteBase64Async(buffer, index, count).ConfigureAwait(false);
1120await _writer.FlushAsync().ConfigureAwait(false);
1136await AdvanceStateAsync(Token.Text).ConfigureAwait(false);
1157await WriteStringAsync(prefix).ConfigureAwait(false);
1158await WriteStringAsync(":").ConfigureAwait(false);
1160await WriteStringAsync(localName).ConfigureAwait(false);
1164await _rawWriter.WriteQualifiedNameAsync(prefix, localName, ns).ConfigureAwait(false);
1182await AdvanceStateAsync(Token.Text).ConfigureAwait(false);
1183await base.WriteBinHexAsync(buffer, index, count).ConfigureAwait(false);
1196await AdvanceStateAsync(Token.StartDocument).ConfigureAwait(false);
1212await _rawWriter.WriteXmlDeclarationAsync(standalone).ConfigureAwait(false);
1218await _writer.WriteStartDocumentAsync().ConfigureAwait(false);
1244await task.ConfigureAwait(false);
1263await task.ConfigureAwait(false);
1265await AdvanceStateAsync(token).ConfigureAwait(false);
1385await _nsStack[i].WriteDeclAsync(_writer, _rawWriter).ConfigureAwait(false);
1414await WriteEndElementAsync().ConfigureAwait(false);
1424await AdvanceStateAsync(Token.EndElement).ConfigureAwait(false);
1436await _rawWriter.WriteEndBase64Async().ConfigureAwait(false);
1439await _writer.FlushAsync().ConfigureAwait(false);
System\Xml\Core\XmlWellFormedWriterHelpersAsync.cs (15)
34await rawWriter.WriteNamespaceDeclarationAsync(prefix, namespaceUri).ConfigureAwait(false);
40await writer.WriteStartAttributeAsync(string.Empty, "xmlns", XmlReservedNs.NsXmlNs).ConfigureAwait(false);
44await writer.WriteStartAttributeAsync("xmlns", prefix, XmlReservedNs.NsXmlNs).ConfigureAwait(false);
46await writer.WriteStringAsync(namespaceUri).ConfigureAwait(false);
47await writer.WriteEndAttributeAsync().ConfigureAwait(false);
58await writer.WriteStringAsync(_singleStringValue).ConfigureAwait(false);
69await writer.WriteEntityRefAsync((string)item.data).ConfigureAwait(false);
72await writer.WriteCharEntityAsync((char)item.data).ConfigureAwait(false);
76await writer.WriteSurrogateCharEntityAsync(chars[0], chars[1]).ConfigureAwait(false);
79await writer.WriteWhitespaceAsync((string)item.data).ConfigureAwait(false);
82await writer.WriteStringAsync((string)item.data).ConfigureAwait(false);
86await writer.WriteCharsAsync(bufChunk.buffer, bufChunk.index, bufChunk.count).ConfigureAwait(false);
89await writer.WriteRawAsync((string)item.data).ConfigureAwait(false);
93await writer.WriteCharsAsync(bufChunk.buffer, bufChunk.index, bufChunk.count).ConfigureAwait(false);
96await writer.WriteStringAsync((string)item.data).ConfigureAwait(false);
System\Xml\Core\XmlWriterAsync.cs (53)
79await task.ConfigureAwait(false);
80await WriteStringAsync(value).ConfigureAwait(false);
81await WriteEndAttributeAsync().ConfigureAwait(false);
222await WriteStringAsync(prefix).ConfigureAwait(false);
223await WriteStringAsync(":").ConfigureAwait(false);
225await WriteStringAsync(localName).ConfigureAwait(false);
242await WriteAttributesAsync(reader, defattr).ConfigureAwait(false);
258await WriteStartAttributeAsync(reader.Prefix, reader.LocalName, reader.NamespaceURI).ConfigureAwait(false);
263await WriteEntityRefAsync(reader.Name).ConfigureAwait(false);
267await WriteStringAsync(reader.Value).ConfigureAwait(false);
270await WriteEndAttributeAsync().ConfigureAwait(false);
305await WriteStartElementAsync(reader.Prefix, reader.LocalName, reader.NamespaceURI).ConfigureAwait(false);
306await WriteAttributesAsync(reader, defattr).ConfigureAwait(false);
309await WriteEndElementAsync().ConfigureAwait(false);
319await WriteCharsAsync(_writeNodeBuffer, 0, read).ConfigureAwait(false);
324await WriteStringAsync(reader.Value).ConfigureAwait(false);
329await WriteWhitespaceAsync(reader.Value).ConfigureAwait(false);
332await WriteCDataAsync(reader.Value).ConfigureAwait(false);
335await WriteEntityRefAsync(reader.Name).ConfigureAwait(false);
339await WriteProcessingInstructionAsync(reader.Name, reader.Value).ConfigureAwait(false);
342await WriteDocTypeAsync(reader.Name, reader.GetAttribute("PUBLIC"), reader.GetAttribute("SYSTEM"), reader.Value).ConfigureAwait(false);
346await WriteCommentAsync(reader.Value).ConfigureAwait(false);
349await WriteFullEndElementAsync().ConfigureAwait(false);
367await WriteStartElementAsync(reader.Prefix, reader.LocalName, reader.NamespaceURI).ConfigureAwait(false);
368await WriteAttributesAsync(reader, defattr).ConfigureAwait(false);
371await WriteEndElementAsync().ConfigureAwait(false);
381await WriteCharsAsync(_writeNodeBuffer, 0, read).ConfigureAwait(false);
387await WriteStringAsync(await reader.GetValueAsync().ConfigureAwait(false)).ConfigureAwait(false);
392await WriteWhitespaceAsync(await reader.GetValueAsync().ConfigureAwait(false)).ConfigureAwait(false);
395await WriteCDataAsync(reader.Value).ConfigureAwait(false);
398await WriteEntityRefAsync(reader.Name).ConfigureAwait(false);
402await WriteProcessingInstructionAsync(reader.Name, reader.Value).ConfigureAwait(false);
405await WriteDocTypeAsync(reader.Name, reader.GetAttribute("PUBLIC"), reader.GetAttribute("SYSTEM"), reader.Value).ConfigureAwait(false);
409await WriteCommentAsync(reader.Value).ConfigureAwait(false);
412await WriteFullEndElementAsync().ConfigureAwait(false);
438await WriteStartElementAsync(navigator.Prefix, navigator.LocalName, navigator.NamespaceURI).ConfigureAwait(false);
448await WriteStartAttributeAsync(navigator.Prefix, navigator.LocalName, navigator.NamespaceURI).ConfigureAwait(false);
450await WriteStringAsync(navigator.Value).ConfigureAwait(false);
451await WriteEndAttributeAsync().ConfigureAwait(false);
460await WriteLocalNamespacesAsync(navigator).ConfigureAwait(false);
469await WriteStringAsync(navigator.Value).ConfigureAwait(false);
473await WriteWhitespaceAsync(navigator.Value).ConfigureAwait(false);
479await WriteCommentAsync(navigator.Value).ConfigureAwait(false);
482await WriteProcessingInstructionAsync(navigator.LocalName, navigator.Value).ConfigureAwait(false);
506await WriteEndElementAsync().ConfigureAwait(false);
510await WriteFullEndElementAsync().ConfigureAwait(false);
536await WriteFullEndElementAsync().ConfigureAwait(false);
547await WriteStartElementAsync(prefix, localName, ns).ConfigureAwait(false);
550await WriteStringAsync(value).ConfigureAwait(false);
552await WriteEndElementAsync().ConfigureAwait(false);
564await WriteLocalNamespacesAsync(nsNav).ConfigureAwait(false);
569await WriteAttributeStringAsync(string.Empty, "xmlns", XmlReservedNs.NsXmlNs, ns).ConfigureAwait(false);
573await WriteAttributeStringAsync("xmlns", prefix, XmlReservedNs.NsXmlNs, ns).ConfigureAwait(false);
System.Private.Xml.Linq (29)
System.Security.Cryptography (6)
System.Security.Cryptography.Cose (6)
System\Security\Cryptography\Cose\CoseMultiSignMessage.cs (3)
408await WriteSignatureAsync(writer, signer, buffer, buffer.AsMemory(0, protectedMapBytesWritten), associatedData, content, cancellationToken).ConfigureAwait(false);
487await AppendToBeSignedAsync(buffer, toBeSignedBuilder, SigStructureContext.Signature, bodyProtected, buffer.AsMemory(start, signProtectedBytesWritten), associatedData, contentStream, cancellationToken).ConfigureAwait(false);
861await AppendToBeSignedAsync(buffer, toBeSignedBuilder, SigStructureContext.Signature, _protectedHeaderAsBstr, encodedSignProtected, associatedData, content, cancellationToken).ConfigureAwait(false);
System\Security\Cryptography\Cose\CoseSign1Message.cs (2)
346await AppendToBeSignedAsync(buffer, toBeSignedBuilder, SigStructureContext.Signature1, buffer.AsMemory(0, protectedMapBytesWritten), ReadOnlyMemory<byte>.Empty, associatedData, content, cancellationToken).ConfigureAwait(false);
950await AppendToBeSignedAsync(buffer, toBeSignedBuilder, SigStructureContext.Signature1, _protectedHeaderAsBstr, ReadOnlyMemory<byte>.Empty, associatedData, content, cancellationToken).ConfigureAwait(false);
System.ServiceModel.Primitives (11)
System\ServiceModel\Channels\BufferedWriteStream.cs (10)
188await _sem.WaitAsync().ConfigureAwait(false);
193await FlushWriteAsync(cancellationToken).ConfigureAwait(false);
199await _stream.FlushAsync(cancellationToken).ConfigureAwait(false);
225await _stream.WriteAsync(_buffer, 0, _writePos, cancellationToken).ConfigureAwait(false);
227await _stream.FlushAsync(cancellationToken).ConfigureAwait(false);
468await semaphoreLockTask.ConfigureAwait(false);
496await _stream.WriteAsync(_buffer, 0, _writePos, cancellationToken).ConfigureAwait(false);
519await _stream.WriteAsync(_buffer, 0, totalUserBytes, cancellationToken).ConfigureAwait(false);
524await _stream.WriteAsync(_buffer, 0, _writePos, cancellationToken).ConfigureAwait(false);
529await _stream.WriteAsync(array, offset, count, cancellationToken).ConfigureAwait(false);
System.Text.Json (3)
System.Threading.RateLimiting (1)
System.Threading.Tasks.Dataflow (4)
System.Windows.Forms (4)
System.Windows.Forms.Analyzers.CSharp.Tests (2)
System.Windows.Forms.Tests (34)
System.Windows.Forms.UI.IntegrationTests (4)
Test.Utilities (14)
src\Dependencies\Threading\ProducerConsumer.cs (8)
37await consumeItems(items.ToImmutableAndClear(), args, cancellationToken).ConfigureAwait(false);
77await args.consumeItems(items.ReadAllAsync(cancellationToken), args.args, cancellationToken).ConfigureAwait(false);
114await args.consumeItems(items, args.args, cancellationToken).ConfigureAwait(false);
238await args.produceItems(source, callback, args.args, cancellationToken).ConfigureAwait(false)),
299source, callback, args.args, cancellationToken).ConfigureAwait(false)),
344await Task.WhenAll(writeTask, readTask).ConfigureAwait(false);
367await produceItems(item => channel.Writer.TryWrite(item), args, cancellationToken).ConfigureAwait(false);
384await action(args, cancellationToken).ConfigureAwait(false);
TestDiscoveryWorker (1)
Text.Analyzers (20)
src\Dependencies\Threading\ProducerConsumer.cs (8)
37await consumeItems(items.ToImmutableAndClear(), args, cancellationToken).ConfigureAwait(false);
77await args.consumeItems(items.ReadAllAsync(cancellationToken), args.args, cancellationToken).ConfigureAwait(false);
114await args.consumeItems(items, args.args, cancellationToken).ConfigureAwait(false);
238await args.produceItems(source, callback, args.args, cancellationToken).ConfigureAwait(false)),
299source, callback, args.args, cancellationToken).ConfigureAwait(false)),
344await Task.WhenAll(writeTask, readTask).ConfigureAwait(false);
367await produceItems(item => channel.Writer.TryWrite(item), args, cancellationToken).ConfigureAwait(false);
384await action(args, cancellationToken).ConfigureAwait(false);
vbc (11)
src\Compilers\Shared\BuildProtocol.cs (7)
128await ReadAllAsync(inStream, lengthBuffer, 4, cancellationToken).ConfigureAwait(false);
187cancellationToken).ConfigureAwait(false);
190await memoryStream.CopyToAsync(outStream, bufferSize: length, cancellationToken: cancellationToken).ConfigureAwait(false);
305cancellationToken).ConfigureAwait(false);
308await memoryStream.CopyToAsync(outStream, bufferSize: length, cancellationToken: cancellationToken).ConfigureAwait(false);
324await ReadAllAsync(stream, lengthBuffer, 4, cancellationToken).ConfigureAwait(false);
332cancellationToken).ConfigureAwait(false);
VBCSCompiler (14)
src\Compilers\Shared\BuildProtocol.cs (7)
128await ReadAllAsync(inStream, lengthBuffer, 4, cancellationToken).ConfigureAwait(false);
187cancellationToken).ConfigureAwait(false);
190await memoryStream.CopyToAsync(outStream, bufferSize: length, cancellationToken: cancellationToken).ConfigureAwait(false);
305cancellationToken).ConfigureAwait(false);
308await memoryStream.CopyToAsync(outStream, bufferSize: length, cancellationToken: cancellationToken).ConfigureAwait(false);
324await ReadAllAsync(stream, lengthBuffer, 4, cancellationToken).ConfigureAwait(false);
332cancellationToken).ConfigureAwait(false);
VBCSCompiler.UnitTests (1)