2894 references to ConfigureAwait
AnalyzerRunner (6)
aspire (6)
Aspire.Cli.Tests (1)
Aspire.Dashboard (42)
Aspire.Dashboard.Components.Tests (2)
Aspire.Dashboard.Tests (2)
Aspire.EndToEnd.Tests (5)
Aspire.Hosting (122)
Dcp\DcpExecutor.cs (26)
122await _executorEvents.PublishAsync(new OnResourcesPreparedContext(cancellationToken)).ConfigureAwait(false);
127await CreateServicesAsync(cancellationToken).ConfigureAwait(false);
129await CreateContainerNetworksAsync(cancellationToken).ConfigureAwait(false);
131await CreateContainersAndExecutablesAsync(cancellationToken).ConfigureAwait(false);
171await Task.WhenAll(tasks).WaitAsync(cancellationToken).ConfigureAwait(false);
186await _kubernetesService.CleanupResourcesAsync(cancellationToken).ConfigureAwait(false);
195await _kubernetesService.StopServerAsync(Model.ResourceCleanup.Full, cancellationToken).ConfigureAwait(false);
211await StopAsync(disposeCts.Token).ConfigureAwait(false);
301await outputSemaphore.WaitAsync(pipelineCancellationToken).ConfigureAwait(false);
305await handler(eventType, resource).ConfigureAwait(false);
372await _executorEvents.PublishAsync(new OnResourceChangedContext(_shutdownCancellation.Token, resourceType, appModelResource, resource.Metadata.Name, status, s => snapshotFactory(resource, s))).ConfigureAwait(false);
594})).ConfigureAwait(false);
633await CreateResourcesAsync<Service>(cancellationToken).ConfigureAwait(false);
710await _executorEvents.PublishAsync(new OnEndpointsAllocatedContext(cancellationToken)).ConfigureAwait(false);
715await Task.WhenAll(containersTask, executablesTask).ConfigureAwait(false);
948await ProcessUrls(resource, cancellationToken).ConfigureAwait(false);
969await CreateExecutableAsync(er, resourceLogger, cancellationToken).ConfigureAwait(false);
1195await CreateContainerAsync(cr, logger, cancellationToken).ConfigureAwait(false);
1222await ProcessUrls(cr.ModelResource, cancellationToken).ConfigureAwait(false);
1237await Task.WhenAll(tasks).ConfigureAwait(false);
1252await ApplyBuildArgumentsAsync(dcpContainerResource, modelContainerResource, cancellationToken).ConfigureAwait(false);
1493await callback.Callback(urlsCallbackContext).ConfigureAwait(false);
1626await EnsureResourceDeletedAsync<Container>(appResource.DcpResourceName).ConfigureAwait(false);
1629await CreateContainerAsync(appResource, resourceLogger, cancellationToken).ConfigureAwait(false);
1632await EnsureResourceDeletedAsync<Executable>(appResource.DcpResourceName).ConfigureAwait(false);
1635await CreateExecutableAsync(appResource, resourceLogger, cancellationToken).ConfigureAwait(false);
Orchestrator\ApplicationOrchestrator.cs (30)
97await _eventing.PublishAsync(afterEndpointsAllocatedEvent, context.CancellationToken).ConfigureAwait(false);
101await lifecycleHook.AfterEndpointsAllocatedAsync(_model, context.CancellationToken).ConfigureAwait(false);
117.ConfigureAwait(false);
119await SetExecutableChildResourceAsync(context.Resource).ConfigureAwait(false);
129.ConfigureAwait(false);
132await SetChildResourceAsync(context.Resource, context.DcpResourceName, state: KnownResourceStates.Starting, startTimeStamp: null, stopTimeStamp: null).ConfigureAwait(false);
138await PublishConnectionStringAvailableEvent(context.Resource, context.CancellationToken).ConfigureAwait(false);
141await _eventing.PublishAsync(beforeResourceStartedEvent, context.CancellationToken).ConfigureAwait(false);
153await PublishResourcesWithInitialStateAsync().ConfigureAwait(false);
171.ConfigureAwait(false);
183.ConfigureAwait(false);
202await _notificationService.PublishUpdateAsync(context.Resource, context.DcpResourceName, context.UpdateSnapshot).ConfigureAwait(false);
206await SetChildResourceAsync(context.Resource, context.DcpResourceName, context.Status.State, context.Status.StartupTimestamp, context.Status.FinishedTimestamp).ConfigureAwait(false);
214await _notificationService.PublishUpdateAsync(context.Resource, context.DcpResourceName, s => s with { State = KnownResourceStates.FailedToStart }).ConfigureAwait(false);
218await SetChildResourceAsync(context.Resource, context.DcpResourceName, KnownResourceStates.FailedToStart, startTimeStamp: null, stopTimeStamp: null).ConfigureAwait(false);
223await _notificationService.PublishUpdateAsync(context.Resource, s => s with { State = KnownResourceStates.FailedToStart }).ConfigureAwait(false);
229await _dcpExecutor.RunApplicationAsync(cancellationToken).ConfigureAwait(false);
232await _eventing.PublishAsync(afterResourcesCreatedEvent, cancellationToken).ConfigureAwait(false);
236await lifecycleHook.AfterResourcesCreatedAsync(_model, cancellationToken).ConfigureAwait(false);
244await _dcpExecutor.StopAsync(cancellationToken).ConfigureAwait(false);
266}).ConfigureAwait(false);
272await _dcpExecutor.StartResourceAsync(resourceReference, cancellationToken).ConfigureAwait(false);
279await _dcpExecutor.StopResourceAsync(resourceReference, cancellationToken).ConfigureAwait(false);
292}).ConfigureAwait(false);
297.ConfigureAwait(false);
312}).ConfigureAwait(false);
314await SetExecutableChildResourceAsync(child).ConfigureAwait(false);
329}).ConfigureAwait(false);
350await _eventing.PublishAsync(connectionStringAvailableEvent, cancellationToken).ConfigureAwait(false);
360await PublishConnectionStringAvailableEvent(child, cancellationToken).ConfigureAwait(false);
Aspire.Hosting.Azure (18)
Aspire.Hosting.Azure.AppContainers (2)
Aspire.Hosting.Azure.AppService (2)
Aspire.Hosting.Docker (8)
Aspire.Hosting.Kafka.Tests (2)
Aspire.Hosting.Kubernetes (6)
Aspire.Hosting.MySql (2)
Aspire.Hosting.MySql.Tests (2)
Aspire.Hosting.NodeJs.Tests (2)
Aspire.Hosting.PostgreSQL (2)
Aspire.Hosting.PostgreSQL.Tests (2)
Aspire.Hosting.RabbitMQ.Tests (2)
Aspire.Hosting.SqlServer (2)
Aspire.Hosting.Testing (5)
Aspire.Hosting.Testing.Tests (1)
Aspire.Hosting.Tests (4)
Aspire.Hosting.Valkey.Tests (2)
Aspire.Playground.Tests (3)
Aspire.Templates.Tests (5)
Binding.Tcp.IntegrationTests (1)
csc (11)
src\Compilers\Core\CommandLine\BuildProtocol.cs (7)
126await ReadAllAsync(inStream, lengthBuffer, 4, cancellationToken).ConfigureAwait(false);
185cancellationToken).ConfigureAwait(false);
188await memoryStream.CopyToAsync(outStream, bufferSize: length, cancellationToken: cancellationToken).ConfigureAwait(false);
303cancellationToken).ConfigureAwait(false);
306await memoryStream.CopyToAsync(outStream, bufferSize: length, cancellationToken: cancellationToken).ConfigureAwait(false);
322await ReadAllAsync(stream, lengthBuffer, 4, cancellationToken).ConfigureAwait(false);
330cancellationToken).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);
dotnet-svcutil-lib.Tests (1)
GenerateDocumentationAndConfigFiles (11)
GenerateRulesMissingDocumentation (4)
http2cat (2)
HttpStress (1)
IdeBenchmarks (2)
IdeCoreBenchmarks (2)
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)
InteropClient (4)
InteropWebsite (1)
LargeResponseApp (1)
Metrics (3)
Metrics.Legacy (3)
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.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.Common (2)
Microsoft.AspNetCore.SignalR.Core (4)
Microsoft.AspNetCore.SignalR.Protocols.MessagePack (2)
Microsoft.AspNetCore.SignalR.Protocols.NewtonsoftJson (2)
Microsoft.AspNetCore.SignalR.Specification.Tests (2)
Microsoft.Build (3)
Microsoft.Build.Tasks.CodeAnalysis (11)
src\Compilers\Core\CommandLine\BuildProtocol.cs (7)
126await ReadAllAsync(inStream, lengthBuffer, 4, cancellationToken).ConfigureAwait(false);
185cancellationToken).ConfigureAwait(false);
188await memoryStream.CopyToAsync(outStream, bufferSize: length, cancellationToken: cancellationToken).ConfigureAwait(false);
303cancellationToken).ConfigureAwait(false);
306await memoryStream.CopyToAsync(outStream, bufferSize: length, cancellationToken: cancellationToken).ConfigureAwait(false);
322await ReadAllAsync(stream, lengthBuffer, 4, cancellationToken).ConfigureAwait(false);
330cancellationToken).ConfigureAwait(false);
Microsoft.Build.Tasks.Core (3)
Microsoft.CodeAnalysis (24)
DiagnosticAnalyzer\AnalyzerDriver.cs (12)
643await ExecutePrimaryAnalysisTaskAsync(analysisScope, usingPrePopulatedEventQueue: true, cancellationToken).ConfigureAwait(false);
697await WhenInitializedTask.ConfigureAwait(false);
705await ProcessCompilationEventsAsync(analysisScope, usingPrePopulatedEventQueue, cancellationToken).ConfigureAwait(false);
868await this.WhenCompletedTask.ConfigureAwait(false);
1542await Task.WhenAll(workerTasks.Concat(syntaxTreeActionsTask).Concat(additionalFileActionsTask)).ConfigureAwait(false);
1565await ProcessEventAsync(completedEvent, analysisScope, cancellationToken).ConfigureAwait(false);
1622await ProcessEventAsync(compilationEvent, analysisScope, cancellationToken).ConfigureAwait(false);
1652await OnEventProcessedCoreAsync(e, processedAnalyzers, analysisScope, cancellationToken).ConfigureAwait(false);
1664await onSymbolAndMembersProcessedAsync(symbolDeclaredEvent.Symbol, analyzer).ConfigureAwait(false);
1696await processContainerOnMemberCompletedAsync(symbol.ContainingNamespace, symbol, analyzer).ConfigureAwait(false);
1699await processContainerOnMemberCompletedAsync(type, symbol, analyzer).ConfigureAwait(false);
1709await 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.CodeStyle (15)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Utilities\ProducerConsumer.cs (8)
55await consumeItems(items.ToImmutableAndClear(), args, cancellationToken).ConfigureAwait(false);
95await args.consumeItems(items.ReadAllAsync(cancellationToken), args.args, cancellationToken).ConfigureAwait(false);
132await args.consumeItems(items, args.args, cancellationToken).ConfigureAwait(false);
256await args.produceItems(source, callback, args.args, cancellationToken).ConfigureAwait(false)),
317source, callback, args.args, cancellationToken).ConfigureAwait(false)),
362await Task.WhenAll(writeTask, readTask).ConfigureAwait(false);
385await produceItems(item => channel.Writer.TryWrite(item), args, cancellationToken).ConfigureAwait(false);
402await action(args, cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.CodeStyle.Fixes (20)
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 (4)
Microsoft.CodeAnalysis.CSharp.CodeStyle.UnitTests (5)
Microsoft.CodeAnalysis.CSharp.EditorFeatures (1)
Microsoft.CodeAnalysis.CSharp.EditorFeatures.UnitTests (144)
CodeActions\MoveStaticMembers\CSharpMoveStaticMembersTests.cs (87)
53await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
84await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
121await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
158await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
213await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
245await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
282await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
323await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
370await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
418await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
477await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
514await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
552await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
574await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
599await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
638await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
686}.RunAsync().ConfigureAwait(false);
723await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
760await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
813await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
868await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
914await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
954await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
1012await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
1065await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
1124await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
1181await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
1243await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
1306await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
1361await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
1437}.RunAsync().ConfigureAwait(false);
1501await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
1565await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
1658}.RunAsync().ConfigureAwait(false);
1719await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
1783await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
1847await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
1920await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
2010await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
2112await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
2149await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
2193await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
2228selectedDestinationName).ConfigureAwait(false);
2261selectedDestinationName).ConfigureAwait(false);
2300selectedDestinationName).ConfigureAwait(false);
2339selectedDestinationName).ConfigureAwait(false);
2396selectedDestinationName).ConfigureAwait(false);
2429selectedDestinationName).ConfigureAwait(false);
2480selectedDestinationName).ConfigureAwait(false);
2525selectedDestinationName).ConfigureAwait(false);
2573selectedDestinationName).ConfigureAwait(false);
2620selectedDestinationName).ConfigureAwait(false);
2670selectedDestinationName).ConfigureAwait(false);
2711await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
2742await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
2773await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
2804await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
2835await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
2872await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
2905await TestMovementNewFileAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
2938await TestMovementNewFileWithSelectionAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
2981await TestMovementNewFileWithSelectionAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
3024await TestMovementNewFileWithSelectionAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
3067await TestMovementNewFileWithSelectionAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
3110await TestMovementNewFileWithSelectionAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
3144await TestMovementNewFileWithSelectionAsync(initialMarkup, expectedResult1, expectedResult2, newFileName, selectedMembers, selectedDestinationName).ConfigureAwait(false);
3158await TestNoRefactoringAsync(initialMarkup).ConfigureAwait(false);
3173await TestNoRefactoringAsync(initialMarkup).ConfigureAwait(false);
3190await TestNoRefactoringAsync(initialMarkup).ConfigureAwait(false);
3207await TestNoRefactoringAsync(initialMarkup).ConfigureAwait(false);
3227}.RunAsync().ConfigureAwait(false);
3244}.RunAsync().ConfigureAwait(false);
3261}.RunAsync().ConfigureAwait(false);
3278}.RunAsync().ConfigureAwait(false);
3295}.RunAsync().ConfigureAwait(false);
3309await TestNoRefactoringAsync(initialMarkup).ConfigureAwait(false);
3323await TestNoRefactoringAsync(initialMarkup).ConfigureAwait(false);
3339await TestNoRefactoringAsync(initialMarkup).ConfigureAwait(false);
3355await TestNoRefactoringAsync(initialMarkup).ConfigureAwait(false);
3372await TestNoRefactoringAsync(initialMarkup).ConfigureAwait(false);
3392}.RunAsync().ConfigureAwait(false);
3412}.RunAsync().ConfigureAwait(false);
3435}.RunAsync().ConfigureAwait(false);
3499}.RunAsync().ConfigureAwait(false);
3519}.RunAsync().ConfigureAwait(false);
3544await test.RunAsync().ConfigureAwait(false);
3552}.RunAsync().ConfigureAwait(false);
Formatting\Indentation\SmartIndenterEnterOnTokenTests.cs (4)
1387await AssertIndentUsingSmartTokenFormatterAsync(code, ch, indentationLine, expectedIndentation, useTabs: false).ConfigureAwait(false);
1388await AssertIndentUsingSmartTokenFormatterAsync(code.Replace(" ", "\t"), ch, indentationLine, expectedIndentation, useTabs: true).ConfigureAwait(false);
1427await AssertIndentNotUsingSmartTokenFormatterButUsingIndenterAsync(code, indentationLine, expectedIndentation, useTabs: false, indentStyle).ConfigureAwait(false);
1428await AssertIndentNotUsingSmartTokenFormatterButUsingIndenterAsync(code.Replace(" ", "\t"), indentationLine, expectedIndentation, useTabs: true, indentStyle).ConfigureAwait(false);
Formatting\Indentation\SmartTokenFormatterFormatRangeTests.cs (2)
3406await AutoFormatOnMarkerAsync(initialMarkup, expected, useTabs: false, tokenKind, startTokenKind).ConfigureAwait(false);
3407await AutoFormatOnMarkerAsync(initialMarkup.Replace(" ", "\t"), expected.Replace(" ", "\t"), useTabs: true, tokenKind, startTokenKind).ConfigureAwait(false);
Formatting\Indentation\SmartTokenFormatterFormatTokenTests.cs (12)
554await AssertSmartTokenFormatterOpenBraceWithBaseIndentationAsync(markup, baseIndentation, expectedIndentation, useTabs: false).ConfigureAwait(false);
555await AssertSmartTokenFormatterOpenBraceWithBaseIndentationAsync(markup.Replace(" ", "\t"), baseIndentation, expectedIndentation, useTabs: true).ConfigureAwait(false);
579await AssertSmartTokenFormatterOpenBraceAsync(code, indentationLine, expectedSpace, useTabs: false, baseIndentation, span).ConfigureAwait(false);
580await AssertSmartTokenFormatterOpenBraceAsync(code.Replace(" ", "\t"), indentationLine, expectedSpace, useTabs: true, baseIndentation, span).ConfigureAwait(false);
600await AssertSmartTokenFormatterOpenBraceAsync(expected, code, indentationLine, useTabs: false).ConfigureAwait(false);
601await AssertSmartTokenFormatterOpenBraceAsync(expected.Replace(" ", "\t"), code.Replace(" ", "\t"), indentationLine, useTabs: true).ConfigureAwait(false);
621await AssertSmartTokenFormatterCloseBraceWithBaseIndentation(markup, baseIndentation, expectedIndentation, useTabs: false).ConfigureAwait(false);
622await AssertSmartTokenFormatterCloseBraceWithBaseIndentation(markup.Replace(" ", "\t"), baseIndentation, expectedIndentation, useTabs: true).ConfigureAwait(false);
646await AssertSmartTokenFormatterCloseBraceAsync(code, indentationLine, expectedSpace, useTabs: false, baseIndentation, span).ConfigureAwait(false);
647await AssertSmartTokenFormatterCloseBraceAsync(code.Replace(" ", "\t"), indentationLine, expectedSpace, useTabs: true, baseIndentation, span).ConfigureAwait(false);
666await ExpectException_SmartTokenFormatterCloseBraceAsync(code, indentationLine, useTabs: false).ConfigureAwait(false);
667await ExpectException_SmartTokenFormatterCloseBraceAsync(code.Replace(" ", "\t"), indentationLine, useTabs: true).ConfigureAwait(false);
Intents\AddConstructorParameterIntentTests.cs (6)
56await VerifyExpectedTextAsync(WellKnownIntents.AddConstructorParameter, initialText, currentText, expectedText).ConfigureAwait(false);
97await VerifyExpectedTextAsync(WellKnownIntents.AddConstructorParameter, initialText, currentText, expectedText).ConfigureAwait(false);
142await VerifyExpectedTextAsync(WellKnownIntents.AddConstructorParameter, initialText, currentText, expectedText).ConfigureAwait(false);
186await VerifyExpectedTextAsync(WellKnownIntents.AddConstructorParameter, initialText, currentText, expectedText).ConfigureAwait(false);
230}).ConfigureAwait(false);
271await VerifyExpectedTextAsync(WellKnownIntents.AddConstructorParameter, initialText, currentText, expectedText).ConfigureAwait(false);
Intents\DeleteParameterIntentTests.cs (11)
61await VerifyExpectedTextAsync(WellKnownIntents.DeleteParameter, initialText, currentText, expectedText).ConfigureAwait(false);
110await VerifyExpectedTextAsync(WellKnownIntents.DeleteParameter, initialText, currentText, expectedText).ConfigureAwait(false);
158await VerifyExpectedTextAsync(WellKnownIntents.DeleteParameter, initialText, currentText, expectedText).ConfigureAwait(false);
206await VerifyExpectedTextAsync(WellKnownIntents.DeleteParameter, initialText, currentText, expectedText).ConfigureAwait(false);
250await VerifyIntentMissingAsync(WellKnownIntents.DeleteParameter, initialText, currentText).ConfigureAwait(false);
313await VerifyExpectedTextAsync(WellKnownIntents.DeleteParameter, initialText, currentText, expectedText).ConfigureAwait(false);
376await VerifyExpectedTextAsync(WellKnownIntents.DeleteParameter, initialText, currentText, expectedText).ConfigureAwait(false);
425await VerifyExpectedTextAsync(WellKnownIntents.DeleteParameter, initialText, currentText, expectedText).ConfigureAwait(false);
474await VerifyExpectedTextAsync(WellKnownIntents.DeleteParameter, initialText, currentText, expectedText).ConfigureAwait(false);
535await VerifyExpectedTextAsync(WellKnownIntents.DeleteParameter, initialText, currentText, expectedText).ConfigureAwait(false);
587await VerifyExpectedTextAsync(WellKnownIntents.DeleteParameter, initialText, currentText, expectedText).ConfigureAwait(false);
Intents\GenerateConstructorIntentTests.cs (7)
51await VerifyExpectedTextAsync(WellKnownIntents.GenerateConstructor, initialText, currentText, expectedText).ConfigureAwait(false);
88await VerifyExpectedTextAsync(WellKnownIntents.GenerateConstructor, initialText, currentText, expectedText).ConfigureAwait(false);
128await VerifyExpectedTextAsync(WellKnownIntents.GenerateConstructor, initialText, currentText, expectedText, intentData: intentData).ConfigureAwait(false);
168await VerifyExpectedTextAsync(WellKnownIntents.GenerateConstructor, initialText, currentText, expectedText, intentData: intentData).ConfigureAwait(false);
208await VerifyExpectedTextAsync(WellKnownIntents.GenerateConstructor, initialText, currentText, additionalDocuments, [expectedText]).ConfigureAwait(false);
245await VerifyExpectedTextAsync(WellKnownIntents.GenerateConstructor, initialText, currentText, expectedText).ConfigureAwait(false);
283}).ConfigureAwait(false);
Intents\RenameIntentTests.cs (4)
52await VerifyExpectedRenameAsync(initialText, currentText, expectedText, "something").ConfigureAwait(false);
92await VerifyExpectedRenameAsync(initialText, currentText, expectedText, "something").ConfigureAwait(false);
132await VerifyExpectedRenameAsync(initialText, currentText, expectedText, "thing").ConfigureAwait(false);
214await VerifyExpectedRenameAsync(initialText, currentText, additionalDocuments, expectedTexts, "BetterString").ConfigureAwait(false);
Microsoft.CodeAnalysis.CSharp.Features (21)
Microsoft.CodeAnalysis.CSharp.Features.UnitTests (7)
Microsoft.CodeAnalysis.CSharp.Workspaces (1)
Microsoft.CodeAnalysis.EditorFeatures (73)
ExtractMethod\ExtractMethodCommandHandler.cs (3)
125await ExecuteWorkerAsync(view, textBuffer, span.Span.ToTextSpan(), indicatorContext).ConfigureAwait(false);
144var result = await ExtractMethodService.ExtractMethodAsync(document, span, localFunction: false, options, cancellationToken).ConfigureAwait(false);
151var localFunctionResult = await ExtractMethodService.ExtractMethodAsync(document, span, localFunction: true, options, cancellationToken).ConfigureAwait(false);
Navigation\AbstractDefinitionLocationService.cs (4)
93symbol, solution, isThirdPartyNavigationAllowed, cancellationToken).ConfigureAwait(false);
119interceptorSymbol, solution, thirdPartyNavigationAllowed: false, cancellationToken).ConfigureAwait(false);
162impl, solution, thirdPartyNavigationAllowed: false, cancellationToken).ConfigureAwait(false));
224documentSpan, classifiedSpans: null, classificationOptions, cancellationToken).ConfigureAwait(false);
Navigation\IDocumentNavigationServiceExtensions.cs (6)
33var location = await service.GetLocationForSpanAsync(workspace, documentId, textSpan, allowInvalidSpan, cancellationToken).ConfigureAwait(false);
40var location = await service.GetLocationForSpanAsync(workspace, documentId, textSpan, cancellationToken).ConfigureAwait(false);
47var location = await service.GetLocationForSpanAsync(workspace, documentId, textSpan, cancellationToken).ConfigureAwait(false);
54var location = await service.GetLocationForPositionAsync(workspace, documentId, position, virtualSpace, allowInvalidPosition, cancellationToken).ConfigureAwait(false);
68workspace, documentId, position, cancellationToken).ConfigureAwait(false);
94workspace, documentId, clampedSpan, allowInvalidSpan: true, cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.EditorFeatures.Test.Utilities (1)
Microsoft.CodeAnalysis.EditorFeatures.UnitTests (5)
InheritanceMargin\InheritanceMarginTests.cs (4)
59await VerifyTestMemberInDocumentAsync(testWorkspace, testHostDocument, memberItems, cancellationToken).ConfigureAwait(false);
88await VerifyTestMemberInDocumentAsync(testWorkspace, testHostDocument, memberItems, cancellationToken).ConfigureAwait(false);
213await VerifyTestMemberInDocumentAsync(testWorkspace, testHostDocument1, memberItemsInMarkup1, cancellationToken).ConfigureAwait(false);
214await VerifyTestMemberInDocumentAsync(testWorkspace, testHostDocument2, memberItemsInMarkup2, cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.ExternalAccess.Debugger (1)
Microsoft.CodeAnalysis.ExternalAccess.Extensions (1)
Microsoft.CodeAnalysis.ExternalAccess.FSharp (5)
Microsoft.CodeAnalysis.ExternalAccess.Razor.Features (6)
Microsoft.CodeAnalysis.ExternalAccess.Xaml (3)
Microsoft.CodeAnalysis.Features (281)
AddImport\AbstractAddImportFeatureService.cs (6)
69var client = await RemoteHostClient.TryGetClientAsync(document.Project, cancellationToken).ConfigureAwait(false);
183allReferences, finder, exact, cancellationToken).ConfigureAwait(false);
193await FindResultsInUnreferencedProjectSourceSymbolsAsync(projectToAssembly, project, allReferences, maxResults, finder, exact, cancellationToken).ConfigureAwait(false);
196await FindResultsInUnreferencedMetadataSymbolsAsync(referenceToCompilation, project, allReferences, maxResults, finder, exact, cancellationToken).ConfigureAwait(false);
200await finder.FindNugetOrReferenceAssemblyReferencesAsync(allReferences, cancellationToken).ConfigureAwait(false);
542var client = await RemoteHostClient.TryGetClientAsync(document.Project, cancellationToken).ConfigureAwait(false);
AddImport\SymbolReferenceFinder_PackageAssemblySearch.cs (5)
40await FindWorkerAsync(new(typeQuery.Name + AttributeSuffix, typeQuery.Arity), namespaceQuery, isAttributeSearch: true).ConfigureAwait(false);
42await FindWorkerAsync(typeQuery, namespaceQuery, isAttributeSearch: false).ConfigureAwait(false);
55allReferences, nameNode, typeQuery, namespaceQuery, isAttributeSearch, cancellationToken).ConfigureAwait(false);
63sourceName, sourceUrl, allReferences, nameNode, typeQuery, namespaceQuery, isAttributeSearch, cancellationToken).ConfigureAwait(false);
140cancellationToken: cancellationToken).ConfigureAwait(false);
ConvertTupleToStruct\AbstractConvertTupleToStructCodeRefactoringProvider.cs (5)
223var client = await RemoteHostClient.TryGetClientAsync(solution.Services, cancellationToken).ConfigureAwait(false);
311containingNamespace, parameterNamingRule, isRecord, cancellationToken).ConfigureAwait(false);
315documentToEditorMap, cancellationToken).ConfigureAwait(false);
470project, result, tupleFieldNames, cancellationToken).ConfigureAwait(false);
483project, result, tupleFieldNames, cancellationToken).ConfigureAwait(false);
Diagnostics\Service\EngineV2\DiagnosticIncrementalAnalyzer.IncrementalMemberEditAnalyzer.cs (6)
114await ExecuteCompilerAnalyzerAsync(compilerAnalyzerData, oldMemberSpans, builder).ConfigureAwait(false);
115await ExecuteSpanBasedAnalyzersAsync(spanBasedAnalyzers, oldMemberSpans, builder).ConfigureAwait(false);
116await ExecuteDocumentBasedAnalyzersAsync(documentBasedAnalyzers, oldMemberSpans, builder).ConfigureAwait(false);
138await ExecuteAnalyzersAsync(executor, analyzers, oldMemberSpans, builder).ConfigureAwait(false);
150await ExecuteAnalyzersAsync(executor, analyzers, oldMemberSpans, builder).ConfigureAwait(false);
162await ExecuteAnalyzersAsync(executor, analyzers, oldMemberSpans, builder).ConfigureAwait(false);
Diagnostics\Service\EngineV2\DiagnosticIncrementalAnalyzer_GetDiagnosticsForSpan.cs (4)
86await GetAsync(list).ConfigureAwait(false);
155await ComputeDocumentDiagnosticsAsync(syntaxAnalyzers.ToImmutable(), AnalysisKind.Syntax, range, list, incrementalAnalysis: false, cancellationToken).ConfigureAwait(false);
156await ComputeDocumentDiagnosticsAsync(semanticSpanBasedAnalyzers.ToImmutable(), AnalysisKind.Semantic, range, list, incrementalAnalysis, cancellationToken).ConfigureAwait(false);
157await ComputeDocumentDiagnosticsAsync(semanticDocumentBasedAnalyzers.ToImmutable(), AnalysisKind.Semantic, span: null, list, incrementalAnalysis: false, cancellationToken).ConfigureAwait(false);
DocumentHighlighting\AbstractDocumentHighlightsService.cs (6)
41var client = await RemoteHostClient.TryGetClientAsync(document.Project, cancellationToken).ConfigureAwait(false);
127documentsToSearch, options, cancellationToken).ConfigureAwait(false);
223await AddLocationSpanAsync(symbol.Locations.First(), solution, spanSet, tagMap, HighlightSpanKind.Definition, cancellationToken).ConfigureAwait(false);
249await AddLocationSpanAsync(location, solution, spanSet, tagMap, HighlightSpanKind.Definition, cancellationToken).ConfigureAwait(false);
258await AddLocationSpanAsync(referenceLocation.Location, solution, spanSet, tagMap, referenceKind, cancellationToken).ConfigureAwait(false);
265await AddLocationSpanAsync(location, solution, spanSet, tagMap, HighlightSpanKind.Reference, cancellationToken).ConfigureAwait(false);
ExternalAccess\UnitTesting\SolutionCrawler\UnitTestingWorkCoordinator.cs (19)
227await EnqueueFullProjectWorkItemAsync(addedProject, UnitTestingInvocationReasons.DocumentAdded).ConfigureAwait(false);
232await EnqueueWorkItemAsync(projectChanges).ConfigureAwait(continueOnCapturedContext: false);
237await EnqueueFullProjectWorkItemAsync(removedProject, UnitTestingInvocationReasons.DocumentRemoved).ConfigureAwait(false);
249await EnqueueFullProjectWorkItemAsync(solution.GetRequiredProject(projectId), invocationReasons).ConfigureAwait(false);
262await EnqueueWorkItemAsync(newProject.GetChanges(oldProject)).ConfigureAwait(false);
291await EnqueueChangedDocumentWorkItemAsync(oldProject.GetRequiredDocument(documentId), newProject.GetRequiredDocument(documentId)).ConfigureAwait(false);
322await EnqueueChangedDocumentWorkItemAsync(oldDocument, newDocument).ConfigureAwait(continueOnCapturedContext: false);
371await EnqueueDocumentWorkItemAsync(project, documentId, document: null, invocationReasons).ConfigureAwait(false);
374await EnqueueDocumentWorkItemAsync(project, documentId, document: null, invocationReasons).ConfigureAwait(false);
377await EnqueueDocumentWorkItemAsync(project, documentId, document: null, invocationReasons).ConfigureAwait(false);
382await EnqueueDocumentWorkItemAsync(project, document.Id, document, invocationReasons).ConfigureAwait(false);
392await EnqueueWorkItemAsync(analyzer, project, documentId, document: null, invocationReasons).ConfigureAwait(false);
409await EnqueueProjectConfigurationChangeWorkItemAsync(projectChanges).ConfigureAwait(false);
412await EnqueueDocumentWorkItemAsync(projectChanges.NewProject, addedDocumentId, document: null, UnitTestingInvocationReasons.DocumentAdded).ConfigureAwait(false);
417.ConfigureAwait(continueOnCapturedContext: false);
421await EnqueueDocumentWorkItemAsync(projectChanges.OldProject, removedDocumentId, document: null, UnitTestingInvocationReasons.DocumentRemoved).ConfigureAwait(false);
454await EnqueueFullProjectWorkItemAsync(projectChanges.NewProject, projectConfigurationChange).ConfigureAwait(false);
466await EnqueueDocumentWorkItemAsync(newDocument.Project, newDocument.Id, newDocument, UnitTestingInvocationReasons.DocumentChanged).ConfigureAwait(false);
473await 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 (7)
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);
133var client = await RemoteHostClient.TryGetClientAsync(solution.Services, cancellationToken).ConfigureAwait(false);
152context, symbol, project, searchOptions, classificationOptions, cancellationToken).ConfigureAwait(false);
239tokenValue, Type.GetTypeCode(tokenValue.GetType()), solution, progressAdapter, cancellationToken).ConfigureAwait(false);
NavigateTo\AbstractNavigateToSearchService.NormalSearch.cs (6)
36var client = await RemoteHostClient.TryGetClientAsync(document.Project, cancellationToken).ConfigureAwait(false);
50await SearchDocumentAndRelatedDocumentsInCurrentProcessAsync(document, searchPattern, kinds, onItemsFound, cancellationToken).ConfigureAwait(false);
97await SearchDocumentsInCurrentProcessAsync(relatedDocuments).ConfigureAwait(false);
164var client = await RemoteHostClient.TryGetClientAsync(solution.Services, cancellationToken).ConfigureAwait(false);
183projects, priorityDocuments, searchPattern, kinds, onItemsFound, onProjectCompleted, cancellationToken).ConfigureAwait(false);
225await onProjectCompleted().ConfigureAwait(false);
NavigateTo\NavigateToSearcher.cs (19)
148await SearchCurrentDocumentAsync(cancellationToken).ConfigureAwait(false);
152await SearchCurrentProjectAsync(documentSupport, cancellationToken).ConfigureAwait(false);
165await SearchAllProjectsAsync(isFullyLoaded, documentSupport, cancellationToken).ConfigureAwait(false);
175await ProgressItemsCompletedAsync(_remainingProgressItems, cancellationToken).ConfigureAwait(false);
191await AddProgressItemsAsync(1, cancellationToken).ConfigureAwait(false);
195cancellationToken).ConfigureAwait(false);
225await SearchSpecificProjectsAsync(isFullyLoaded, documentSupport, orderedProjects, cancellationToken).ConfigureAwait(false);
246using var _2 = await RemoteKeepAliveSession.CreateAsync(_solution, cancellationToken).ConfigureAwait(false);
251cancellationToken).ConfigureAwait(false);
254await SearchFullyLoadedProjectsAsync(orderedProjects, seenItems, cancellationToken).ConfigureAwait(false);
257await SearchGeneratedDocumentsAsync(orderedProjects, seenItems, cancellationToken).ConfigureAwait(false);
265await AddProgressItemsAsync(projectCount, cancellationToken).ConfigureAwait(false);
266await SearchCachedDocumentsAsync(orderedProjects, seenItems, cancellationToken).ConfigureAwait(false);
407() => this.ProgressItemsCompletedAsync(count: 1, cancellationToken)).ConfigureAwait(false);
449await onProjectCompleted().ConfigureAwait(false);
455onResultsFound, onProjectCompleted, cancellationToken).ConfigureAwait(false);
506await onProjectCompleted().ConfigureAwait(false);
511_solution, projects, _searchPattern, _kinds, _activeDocument, onResultsFound, onProjectCompleted, cancellationToken).ConfigureAwait(false);
537await 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 (5)
39var semanticDocument = await SemanticDocument.CreateAsync(document, cancellationToken).ConfigureAwait(false);
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 (8)
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);
239await TrackVariableReferencesAsync(outOrRefParam, collector, cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.InteractiveHost (9)
Microsoft.CodeAnalysis.LanguageServer.Protocol (67)
Features\UnifiedSuggestions\UnifiedSuggestedActionsSource.cs (5)
75await GroupFixesAsync(workspace, originalSolution, fixCollections, map, order, cancellationToken).ConfigureAwait(false);
94await ProcessFixCollectionAsync(workspace, originalSolution, map, order, fixCollection, cancellationToken).ConfigureAwait(false);
111await AddCodeActionsAsync(workspace, originalSolution, map, order, fixCollection, GetFixAllSuggestedActionSetAsync, nonSupressionCodeFixes).ConfigureAwait(false);
115await AddCodeActionsAsync(workspace, originalSolution, map, order, fixCollection, GetFixAllSuggestedActionSetAsync, supressionCodeFixes).ConfigureAwait(false);
447cancellationToken).ConfigureAwait(false);
src\LanguageServer\Microsoft.CommonLanguageServerProtocol.Framework\RequestExecutionQueue.cs (6)
274await InvokeProcessCoreAsync(work, metadata, handler, methodInfo, concurrentlyExecutingTasks, currentWorkCts, cancellationToken).ConfigureAwait(false);
293await _languageServer.ShutdownAsync("Error processing queue, shutting down").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)
Completion\CompletionTests.cs (13)
94request: completionParams, document: document, commitCharacters: CompletionRules.Default.DefaultCommitCharacters).ConfigureAwait(false);
145request: completionParams, document: document, commitCharacters: CompletionRules.Default.DefaultCommitCharacters).ConfigureAwait(false);
178request: completionParams, document: document, commitCharacters: null).ConfigureAwait(false);
212request: completionParams, document: document, commitCharacters: null).ConfigureAwait(false);
251request: completionParams, document: document, commitCharacters: null).ConfigureAwait(false);
279request: completionParams, document: document, commitCharacters: null).ConfigureAwait(false);
357completionParams, document, preselect: true, commitCharacters: ImmutableArray.Create(' ', '(', '[', '{', ';', '.')).ConfigureAwait(false);
416labelDetails: new() { Description = "shortdate" }).ConfigureAwait(false);
477sortText: "0000", labelDetails: new() { Description = "startofstringonly" }).ConfigureAwait(false);
514sortText: "0000", vsResolveTextEditOnCommit: true, labelDetails: new() { Description = "startofstringonly" }).ConfigureAwait(false);
551sortText: "0000", vsResolveTextEditOnCommit: true, labelDetails: new() { Description = "startofstringonly" }).ConfigureAwait(false);
605sortText: "0000", labelDetails: new() { Description = "startofstringonly" }).ConfigureAwait(false);
696completionParams, document, commitCharacters: CompletionRules.Default.DefaultCommitCharacters).ConfigureAwait(false);
Miscellaneous\LspMiscellaneousFilesWorkspaceTests.cs (12)
43await AssertFileInMiscWorkspaceAsync(testLspServer, looseFileUri).ConfigureAwait(false);
69await AssertFileInMiscWorkspaceAsync(testLspServer, looseFileUri).ConfigureAwait(false);
80await AssertFileInMiscWorkspaceAsync(testLspServer, looseFileUri).ConfigureAwait(false);
105await AssertFileInMiscWorkspaceAsync(testLspServer, looseFileUri).ConfigureAwait(false);
155await AssertFileInMiscWorkspaceAsync(testLspServer, looseFileUri).ConfigureAwait(false);
177await AssertFileInMainWorkspaceAsync(testLspServer, looseFileUri).ConfigureAwait(false);
199await AssertFileInMiscWorkspaceAsync(testLspServer, looseFileUri).ConfigureAwait(false);
204await AssertFileInMiscWorkspaceAsync(testLspServer, looseFileUri).ConfigureAwait(false);
232await AssertFileInMiscWorkspaceAsync(testLspServer, looseFileUri).ConfigureAwait(false);
235await AssertFileInMiscWorkspaceAsync(testLspServer, looseFileUri).ConfigureAwait(false);
265await AssertFileInMiscWorkspaceAsync(testLspServer, looseFileUri).ConfigureAwait(false);
307await AssertFileInMiscWorkspaceAsync(testLspServer, looseFileUri).ConfigureAwait(false);
Microsoft.CodeAnalysis.Remote.ServiceHub (35)
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);
Microsoft.CodeAnalysis.Remote.Workspaces (14)
SolutionAssetStorage.Scope.cs (2)
55await FindAssetsAsync(assetPath, checksumsToFind, onAssetFound, arg, cancellationToken).ConfigureAwait(false);
84await stateChecksums.FindAsync(solutionState, this.ProjectCone, assetPath, remainingChecksumsToFind, onAssetFound, arg, cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.Scripting (1)
Microsoft.CodeAnalysis.Test.Utilities (1)
Microsoft.CodeAnalysis.Threading.Package (4)
Microsoft.CodeAnalysis.VisualBasic.EditorFeatures (1)
Microsoft.CodeAnalysis.VisualBasic.Features (3)
Microsoft.CodeAnalysis.Workspaces (151)
Classification\AbstractClassificationService.cs (2)
151document, textSpans, options, getNodeClassifiers, getTokenClassifiers, result, cancellationToken).ConfigureAwait(false);
175document, textSpans, options, result, cancellationToken).ConfigureAwait(false);
Classification\ClassifierHelper.cs (3)
73await classificationService.AddSyntacticClassificationsAsync(document, spans, syntaxSpans, cancellationToken).ConfigureAwait(false);
77await classificationService.AddSemanticClassificationsAsync(document, spans, options, semanticSpans, cancellationToken).ConfigureAwait(false);
78await classificationService.AddEmbeddedLanguageClassificationsAsync(document, spans, options, semanticSpans, cancellationToken).ConfigureAwait(false);
Diagnostics\Extensions.cs (4)
390document, documentAnalysisScope.Span, diagnosticsBuilder.Add, cancellationToken).ConfigureAwait(false);
404document, span: null, callback, cancellationToken).ConfigureAwait(false);
416document, span: null, diagnosticsBuilder.Add, cancellationToken).ConfigureAwait(false);
434semanticModel, span, hostCompilationWithAnalyzers, analyzerInfoCache.GetDiagnosticDescriptors, reportDiagnostic, 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)
136await DescendInheritanceTreeInProjectAsync(project).ConfigureAwait(false);
154await AddDescendantMetadataTypesInProjectAsync(tempBuffer, project).ConfigureAwait(false);
174await AddDescendantSourceTypesInProjectAsync(tempBuffer, project).ConfigureAwait(false);
219predicate: static n => n.BaseType?.SpecialType == SpecialType.System_Object).ConfigureAwait(false);
223projectIndex.ValueTypes, tempBuffer, predicate: null).ConfigureAwait(false);
227projectIndex.Enums, tempBuffer, predicate: null).ConfigureAwait(false);
231projectIndex.Delegates, tempBuffer, predicate: null).ConfigureAwait(false);
235await AddSourceTypesThatDeriveFromNameAsync(tempBuffer, type.Name).ConfigureAwait(false);
320typesToSearchFor, project, compilation, peReference, tempBuffer).ConfigureAwait(false);
FindSymbols\FindReferences\Finders\ConstructorSymbolReferenceFinder.cs (7)
69project, documents, typeName, processResult, processResultData, cancellationToken).ConfigureAwait(false);
76project, documents, globalAlias, processResult, processResultData, cancellationToken).ConfigureAwait(false);
81project, documents, containingType.SpecialType.ToPredefinedType(), processResult, processResultData, cancellationToken).ConfigureAwait(false);
84project, documents, processResult, processResultData, cancellationToken).ConfigureAwait(false);
89project, documents, processResult, processResultData, cancellationToken).ConfigureAwait(false);
104await FindDocumentsAsync(project, documents, processResult, processResultData, cancellationToken, typeName).ConfigureAwait(false);
107await 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)
60await AddDownSymbolsAsync(this.Engine, current, _allSymbols, workQueue, projects, cancellationToken).ConfigureAwait(false);
61await AddUpSymbolsAsync(this.Engine, current, _allSymbols, workQueue, projects, _includeImplementationsThroughDerivedTypes, cancellationToken).ConfigureAwait(false);
FindSymbols\FindReferences\FindReferencesSearchEngine.SymbolSet.cs (8)
158await AddCascadedAndLinkedSymbolsToAsync(engine, currentSymbol, result, workQueue, cancellationToken).ConfigureAwait(false);
178engine, currentSymbol, upSymbols, workQueue, allProjects, includeImplementationsThroughDerivedTypes, cancellationToken).ConfigureAwait(false);
188await AddCascadedAndLinkedSymbolsToAsync(engine, symbol, seenSymbols, workQueue, cancellationToken).ConfigureAwait(false);
253await AddCascadedAndLinkedSymbolsToAsync(engine, implementations, seenSymbols, workQueue, cancellationToken).ConfigureAwait(false);
260await AddCascadedAndLinkedSymbolsToAsync(engine, overrides, seenSymbols, workQueue, cancellationToken).ConfigureAwait(false);
290await AddCascadedAndLinkedSymbolsToAsync(engine, match, seenSymbols, workQueue, cancellationToken).ConfigureAwait(false);
295await AddCascadedAndLinkedSymbolsToAsync(engine, overriddenMember, seenSymbols, workQueue, cancellationToken).ConfigureAwait(false);
298await AddCascadedAndLinkedSymbolsToAsync(engine, symbol.ExplicitInterfaceImplementations(), seenSymbols, workQueue, cancellationToken).ConfigureAwait(false);
Rename\ConflictEngine\ConflictResolver.Session.cs (5)
222_cancellationToken).ConfigureAwait(false);
233await DebugVerifyNoErrorsAsync(conflictResolution, documentsIdsToBeCheckedForConflict).ConfigureAwait(false);
291await conflictResolution.CurrentSolution.GetRequiredDocument(documentId).VerifyNoErrorsAsync("Rename introduced errors in error-free code", _cancellationToken, ignoreErrorCodes).ConfigureAwait(false);
457renamedSymbolInNewSolution, renameSymbol, referencedSymbols, conflictResolution, reverseMappedLocations, _cancellationToken).ConfigureAwait(false);
720await AddDocumentsWithPotentialConflictsAsync(documentsFromAffectedProjects, documentIds, possibleNameConflicts).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Utilities\ProducerConsumer.cs (8)
55await consumeItems(items.ToImmutableAndClear(), args, cancellationToken).ConfigureAwait(false);
95await args.consumeItems(items.ReadAllAsync(cancellationToken), args.args, cancellationToken).ConfigureAwait(false);
132await args.consumeItems(items, args.args, cancellationToken).ConfigureAwait(false);
256await args.produceItems(source, callback, args.args, cancellationToken).ConfigureAwait(false)),
317source, callback, args.args, cancellationToken).ConfigureAwait(false)),
362await Task.WhenAll(writeTask, readTask).ConfigureAwait(false);
385await produceItems(item => channel.Writer.TryWrite(item), args, cancellationToken).ConfigureAwait(false);
402await action(args, cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.Workspaces.MSBuild (2)
Microsoft.CodeAnalysis.Workspaces.MSBuild.BuildHost (7)
Microsoft.CodeAnalysis.Workspaces.MSBuild.UnitTests (4)
Microsoft.CodeAnalysis.Workspaces.Test.Utilities (1)
Microsoft.CodeAnalysis.Workspaces.UnitTests (1)
Microsoft.CommonLanguageServerProtocol.Framework.Package (12)
RequestExecutionQueue.cs (6)
274await InvokeProcessCoreAsync(work, metadata, handler, methodInfo, concurrentlyExecutingTasks, currentWorkCts, cancellationToken).ConfigureAwait(false);
293await _languageServer.ShutdownAsync("Error processing queue, shutting down").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.Evaluation (1)
Microsoft.Extensions.AI.Evaluation.Console (1)
Microsoft.Extensions.AI.Evaluation.Quality (1)
Microsoft.Extensions.AI.Evaluation.Reporting (13)
Microsoft.Extensions.AI.Evaluation.Reporting.Azure (2)
Microsoft.Extensions.AI.Evaluation.Safety (2)
Microsoft.Extensions.AI.OpenAI (1)
Microsoft.Extensions.AI.Templates.Tests (2)
Microsoft.Extensions.Caching.Hybrid (1)
Microsoft.Extensions.Caching.SqlServer (7)
Microsoft.Extensions.Caching.StackExchangeRedis (5)
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 (3)
Microsoft.Extensions.Http.Diagnostics.Tests (1)
Microsoft.Extensions.Http.Polly.Tests (1)
Microsoft.Extensions.Identity.Core (56)
UserManager.cs (49)
464await UpdateSecurityStampInternal(user).ConfigureAwait(false);
472await GetUserLockoutStore().SetLockoutEnabledAsync(user, true, CancellationToken).ConfigureAwait(false);
474await UpdateNormalizedUserNameAsync(user).ConfigureAwait(false);
475await UpdateNormalizedEmailAsync(user).ConfigureAwait(false);
624await Store.SetNormalizedUserNameAsync(user, normalizedName, CancellationToken).ConfigureAwait(false);
650await Store.SetUserNameAsync(user, userName, CancellationToken).ConfigureAwait(false);
651await UpdateSecurityStampInternal(user).ConfigureAwait(false);
850await UpdateSecurityStampInternal(user).ConfigureAwait(false);
932await loginStore.RemoveLoginAsync(user, loginProvider, providerKey, CancellationToken).ConfigureAwait(false);
933await UpdateSecurityStampInternal(user).ConfigureAwait(false);
959await loginStore.AddLoginAsync(user, login, CancellationToken).ConfigureAwait(false);
1012await claimStore.AddClaimsAsync(user, claims, CancellationToken).ConfigureAwait(false);
1034await claimStore.ReplaceClaimAsync(user, claim, newClaim, CancellationToken).ConfigureAwait(false);
1072await claimStore.RemoveClaimsAsync(user, claims, CancellationToken).ConfigureAwait(false);
1111await userRoleStore.AddToRoleAsync(user, normalizedRole, CancellationToken).ConfigureAwait(false);
1138await userRoleStore.AddToRoleAsync(user, normalizedRole, CancellationToken).ConfigureAwait(false);
1163await userRoleStore.RemoveFromRoleAsync(user, normalizedRole, CancellationToken).ConfigureAwait(false);
1208await userRoleStore.RemoveFromRoleAsync(user, normalizedRole, CancellationToken).ConfigureAwait(false);
1271await store.SetEmailAsync(user, email, CancellationToken).ConfigureAwait(false);
1272await store.SetEmailConfirmedAsync(user, false, CancellationToken).ConfigureAwait(false);
1273await UpdateSecurityStampInternal(user).ConfigureAwait(false);
1327await store.SetNormalizedEmailAsync(user, ProtectPersonalData(NormalizeEmail(email)!), CancellationToken).ConfigureAwait(false);
1363await store.SetEmailConfirmedAsync(user, true, CancellationToken).ConfigureAwait(false);
1419await store.SetEmailAsync(user, newEmail, CancellationToken).ConfigureAwait(false);
1420await store.SetEmailConfirmedAsync(user, true, CancellationToken).ConfigureAwait(false);
1421await UpdateSecurityStampInternal(user).ConfigureAwait(false);
1453await store.SetPhoneNumberAsync(user, phoneNumber, CancellationToken).ConfigureAwait(false);
1454await store.SetPhoneNumberConfirmedAsync(user, false, CancellationToken).ConfigureAwait(false);
1455await UpdateSecurityStampInternal(user).ConfigureAwait(false);
1481await store.SetPhoneNumberAsync(user, phoneNumber, CancellationToken).ConfigureAwait(false);
1482await store.SetPhoneNumberConfirmedAsync(user, true, CancellationToken).ConfigureAwait(false);
1483await UpdateSecurityStampInternal(user).ConfigureAwait(false);
1710await store.SetTwoFactorEnabledAsync(user, enabled, CancellationToken).ConfigureAwait(false);
1711await UpdateSecurityStampInternal(user).ConfigureAwait(false);
1752await store.SetLockoutEnabledAsync(user, enabled, CancellationToken).ConfigureAwait(false);
1804await store.SetLockoutEndDateAsync(user, lockoutEnd, CancellationToken).ConfigureAwait(false);
1829CancellationToken).ConfigureAwait(false);
1830await store.ResetAccessFailedCountAsync(user, CancellationToken).ConfigureAwait(false);
1849await store.ResetAccessFailedCountAsync(user, CancellationToken).ConfigureAwait(false);
1935await store.SetTokenAsync(user, loginProvider, tokenName, tokenValue, CancellationToken).ConfigureAwait(false);
1954await store.RemoveTokenAsync(user, loginProvider, tokenName, CancellationToken).ConfigureAwait(false);
1981await store.SetAuthenticatorKeyAsync(user, GenerateNewAuthenticatorKey(), CancellationToken).ConfigureAwait(false);
1982await UpdateSecurityStampInternal(user).ConfigureAwait(false);
2011await store.ReplaceCodesAsync(user, newCodes.Distinct(), CancellationToken).ConfigureAwait(false);
2203await GetSecurityStore().SetSecurityStampAsync(user, NewSecurityStamp(), CancellationToken).ConfigureAwait(false);
2229await passwordStore.SetPasswordHashAsync(user, hash, CancellationToken).ConfigureAwait(false);
2230await UpdateSecurityStampInternal(user).ConfigureAwait(false);
2378await UpdateNormalizedUserNameAsync(user).ConfigureAwait(false);
2379await UpdateNormalizedEmailAsync(user).ConfigureAwait(false);
Microsoft.Extensions.Identity.Stores (3)
Microsoft.Extensions.Logging.AzureAppServices (4)
Microsoft.Extensions.ServiceDiscovery (8)
Microsoft.Extensions.ServiceDiscovery.Dns (1)
Microsoft.Extensions.TimeProvider.Testing.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 (2)
Microsoft.VisualBasic.Forms.Tests (2)
Microsoft.VisualBasic.Tests (1)
Microsoft.VisualStudio.LanguageServices (138)
CodeLens\CodeLensCallbackListener.cs (4)
112return await service.GetReferenceCountAsync(solution, documentId, node, maxSearchResults, cancellationToken).ConfigureAwait(false);
133var references = await service.FindReferenceLocationsAsync(solution, documentId, node, cancellationToken).ConfigureAwait(false);
169return await service.FindReferenceMethodsAsync(solution, documentId, node, cancellationToken).ConfigureAwait(false);
197await EnsureMaxResultAsync(cancellationToken).ConfigureAwait(false);
CodeLens\RemoteCodeLensReferencesService.cs (7)
51var client = await RemoteHostClient.TryGetClientAsync(solution.Services, cancellationToken).ConfigureAwait(false);
62return await CodeLensReferencesServiceFactory.Instance.GetReferenceCountAsync(solution, documentId, syntaxNode, maxSearchResults, cancellationToken).ConfigureAwait(false);
97var client = await RemoteHostClient.TryGetClientAsync(solution.Services, cancellationToken).ConfigureAwait(false);
108return await CodeLensReferencesServiceFactory.Instance.FindReferenceMethodsAsync(solution, documentId, syntaxNode, cancellationToken).ConfigureAwait(false);
122var client = await RemoteHostClient.TryGetClientAsync(solution.Services, cancellationToken).ConfigureAwait(false);
260var client = await RemoteHostClient.TryGetClientAsync(solution.Services, cancellationToken).ConfigureAwait(false);
272return await CodeLensReferencesServiceFactory.Instance.FindReferenceLocationsAsync(solution, documentId, syntaxNode, cancellationToken).ConfigureAwait(false);
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 (3)
Microsoft.VisualStudio.LanguageServices.LiveShare (6)
Microsoft.VisualStudio.LanguageServices.Xaml (3)
Replay (11)
src\Compilers\Core\CommandLine\BuildProtocol.cs (7)
126await ReadAllAsync(inStream, lengthBuffer, 4, cancellationToken).ConfigureAwait(false);
185cancellationToken).ConfigureAwait(false);
188await memoryStream.CopyToAsync(outStream, bufferSize: length, cancellationToken: cancellationToken).ConfigureAwait(false);
303cancellationToken).ConfigureAwait(false);
306await memoryStream.CopyToAsync(outStream, bufferSize: length, cancellationToken: cancellationToken).ConfigureAwait(false);
322await ReadAllAsync(stream, lengthBuffer, 4, cancellationToken).ConfigureAwait(false);
330cancellationToken).ConfigureAwait(false);
Roslyn.Compilers.Extension (2)
Roslyn.Diagnostics.Analyzers (1)
Roslyn.VisualStudio.DiagnosticsWindow (4)
Roslyn.VisualStudio.Next.UnitTests (11)
Sockets.BindTests (8)
Sockets.FunctionalTests (11)
System.Data.Common (13)
System.Diagnostics.Process (5)
System.Formats.Tar (21)
System.IO.Compression (25)
System\IO\Compression\ZipArchive.Async.cs (12)
81await backingStream.CopyToAsync(stream, cancellationToken).ConfigureAwait(false);
93await zipArchive.ReadEndOfCentralDirectoryAsync(cancellationToken).ConfigureAwait(false);
104await zipArchive.ReadEndOfCentralDirectoryAsync(cancellationToken).ConfigureAwait(false);
105await zipArchive.EnsureCentralDirectoryReadAsync(cancellationToken).ConfigureAwait(false);
109await entry.ThrowIfNotOpenableAsync(needToUncompress: false, needToLoadIntoMemory: true, cancellationToken).ConfigureAwait(false);
150await CloseStreamsAsync().ConfigureAwait(false);
184await ReadCentralDirectoryAsync(cancellationToken).ConfigureAwait(false);
346await entry.LoadLocalHeaderExtraFieldIfNeededAsync(cancellationToken).ConfigureAwait(false);
349await entry.LoadCompressedBytesIfNeededAsync(cancellationToken).ConfigureAwait(false);
367await entry.WriteAndFinishLocalEntryAsync(forceWriteLocalEntry, cancellationToken).ConfigureAwait(false);
380await entry.WriteCentralDirectoryFileHeaderAsync(centralDirectoryEntryRequiresUpdate, cancellationToken).ConfigureAwait(false);
423await 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 (3)
System.Net.Ping (1)
System.Net.Quic (3)
System.Net.Requests (2)
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 (76)
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);
887await FlushBufferAsync().ConfigureAwait(false);
912await FlushBufferAsync().ConfigureAwait(false);
920await FlushBufferAsync().ConfigureAwait(false);
1100await RawTextAsync(_newLineChars).ConfigureAwait(false);
1106await FlushBufferAsync().ConfigureAwait(false);
1140await RawTextAsync(_newLineChars).ConfigureAwait(false);
1146await FlushBufferAsync().ConfigureAwait(false);
1157await RawTextAsync(_newLineChars).ConfigureAwait(false);
1163await FlushBufferAsync().ConfigureAwait(false);
1322await FlushBufferAsync().ConfigureAwait(false);
1331await FlushBufferAsync().ConfigureAwait(false);
1338await RawTextAsync(text2, text3, text4).ConfigureAwait(false);
1498await RawTextAsync(_newLineChars).ConfigureAwait(false);
1504await FlushBufferAsync().ConfigureAwait(false);
1522await RawTextAsync(_newLineChars).ConfigureAwait(false);
1528await FlushBufferAsync().ConfigureAwait(false);
1693await FlushBufferAsync().ConfigureAwait(false);
1709await RawTextAsync(_newLineChars).ConfigureAwait(false);
1715await FlushBufferAsync().ConfigureAwait(false);
1877await FlushBufferAsync().ConfigureAwait(false);
1893await RawTextAsync(_newLineChars).ConfigureAwait(false);
1899await FlushBufferAsync().ConfigureAwait(false);
1914await WriteIndentAsync().ConfigureAwait(false);
1916await base.WriteDocTypeAsync(name, pubid, sysid, subset).ConfigureAwait(false);
1927await WriteIndentAsync().ConfigureAwait(false);
1932await base.WriteStartElementAsync(prefix, localName, ns).ConfigureAwait(false);
1945await WriteIndentAsync().ConfigureAwait(false);
1950await base.WriteEndElementAsync(prefix, localName, ns).ConfigureAwait(false);
1963await WriteIndentAsync().ConfigureAwait(false);
1968await base.WriteFullEndElementAsync(prefix, localName, ns).ConfigureAwait(false);
1978await WriteIndentAsync().ConfigureAwait(false);
1981await base.WriteStartAttributeAsync(prefix, localName, ns).ConfigureAwait(false);
1991await WriteIndentAsync().ConfigureAwait(false);
1994await base.WriteStartNamespaceDeclarationAsync(prefix).ConfigureAwait(false);
2009await WriteIndentAsync().ConfigureAwait(false);
2012await base.WriteCommentAsync(text).ConfigureAwait(false);
2020await WriteIndentAsync().ConfigureAwait(false);
2023await base.WriteProcessingInstructionAsync(target, text).ConfigureAwait(false);
2093await RawTextAsync(base._newLineChars).ConfigureAwait(false);
2096await 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);
485await AppendToBeSignedAsync(buffer, hasher, SigStructureContext.Signature, bodyProtected, buffer.AsMemory(start, signProtectedBytesWritten), associatedData, contentStream, cancellationToken).ConfigureAwait(false);
853await AppendToBeSignedAsync(buffer, hasher, SigStructureContext.Signature, _protectedHeaderAsBstr, encodedSignProtected, associatedData, content, cancellationToken).ConfigureAwait(false);
System\Security\Cryptography\Cose\CoseSign1Message.cs (2)
343await AppendToBeSignedAsync(buffer, hasher, SigStructureContext.Signature1, buffer.AsMemory(0, protectedMapBytesWritten), ReadOnlyMemory<byte>.Empty, associatedData, content, cancellationToken).ConfigureAwait(false);
690await AppendToBeSignedAsync(buffer, hasher, SigStructureContext.Signature1, _protectedHeaderAsBstr, ReadOnlyMemory<byte>.Empty, associatedData, content, cancellationToken).ConfigureAwait(false);
System.Text.Json (3)
System.Threading.RateLimiting (1)
System.Threading.Tasks.Dataflow (4)
System.Windows.Forms (5)
System.Windows.Forms.Analyzers.CSharp.Tests (2)
System.Windows.Forms.Analyzers.VisualBasic.Tests (6)
System.Windows.Forms.UI.IntegrationTests (4)
TestDiscoveryWorker (1)
vbc (11)
src\Compilers\Core\CommandLine\BuildProtocol.cs (7)
126await ReadAllAsync(inStream, lengthBuffer, 4, cancellationToken).ConfigureAwait(false);
185cancellationToken).ConfigureAwait(false);
188await memoryStream.CopyToAsync(outStream, bufferSize: length, cancellationToken: cancellationToken).ConfigureAwait(false);
303cancellationToken).ConfigureAwait(false);
306await memoryStream.CopyToAsync(outStream, bufferSize: length, cancellationToken: cancellationToken).ConfigureAwait(false);
322await ReadAllAsync(stream, lengthBuffer, 4, cancellationToken).ConfigureAwait(false);
330cancellationToken).ConfigureAwait(false);
VBCSCompiler (14)
src\Compilers\Core\CommandLine\BuildProtocol.cs (7)
126await ReadAllAsync(inStream, lengthBuffer, 4, cancellationToken).ConfigureAwait(false);
185cancellationToken).ConfigureAwait(false);
188await memoryStream.CopyToAsync(outStream, bufferSize: length, cancellationToken: cancellationToken).ConfigureAwait(false);
303cancellationToken).ConfigureAwait(false);
306await memoryStream.CopyToAsync(outStream, bufferSize: length, cancellationToken: cancellationToken).ConfigureAwait(false);
322await ReadAllAsync(stream, lengthBuffer, 4, cancellationToken).ConfigureAwait(false);
330cancellationToken).ConfigureAwait(false);
VBCSCompiler.UnitTests (1)