2153 references to ConfigureAwait
aspire (2)
Interaction\ExtensionInteractionService.cs (2)
36while (await _extensionTaskChannel.Reader.WaitToReadAsync().ConfigureAwait(false)) 38var taskFunction = await _extensionTaskChannel.Reader.ReadAsync().ConfigureAwait(false);
Aspire.Azure.Npgsql (1)
src\Components\Common\ManagedIdentityTokenCredentialHelpers.cs (1)
59passwordProviderAsync: async (_, ct) => (await credential.GetTokenAsync(s_databaseForPostgresSqlTokenRequestContext, default).ConfigureAwait(false)).Token
Aspire.Azure.Npgsql.EntityFrameworkCore.PostgreSQL (1)
src\Components\Common\ManagedIdentityTokenCredentialHelpers.cs (1)
59passwordProviderAsync: async (_, ct) => (await credential.GetTokenAsync(s_databaseForPostgresSqlTokenRequestContext, default).ConfigureAwait(false)).Token
Aspire.Confluent.Kafka (1)
MetricsService.cs (1)
19while (await channel.Reader.WaitToReadAsync(stoppingToken).ConfigureAwait(false))
Aspire.Dashboard (8)
Model\BrowserStorage\BrowserStorageBase.cs (1)
31var result = await _protectedBrowserStorage.GetAsync<TValue>(key).ConfigureAwait(false);
Model\BrowserStorage\LocalBrowserStorage.cs (1)
27var json = await GetJsonAsync(key).ConfigureAwait(false);
Model\ThemeManager.cs (3)
27_jsModule = await _jsRuntime.InvokeAsync<IJSObjectReference>("import", "/js/app-theme.js").ConfigureAwait(false); 32var currentTheme = await currentThemeTask.ConfigureAwait(false); 33var themeCookieValue = await themeCookieValueTask.ConfigureAwait(false);
Otlp\Http\OtlpHttpEndpointsBuilder.cs (1)
184result = await httpContext.Request.BodyReader.ReadAsync().ConfigureAwait(false);
src\Shared\ChannelExtensions.cs (1)
36if (await channel.Reader.WaitToReadAsync(cancellationToken).ConfigureAwait(false))
Telemetry\DashboardTelemetrySender.cs (1)
51while (await _channel.Reader.WaitToReadAsync().ConfigureAwait(false))
Aspire.Hosting (31)
ApplicationModel\ConnectionStringReference.cs (1)
26var value = await Resource.GetValueAsync(cancellationToken).ConfigureAwait(false);
ApplicationModel\ExpressionResolver.cs (9)
67(EndpointProperty.Port, true, true) => await endpointReference.Property(EndpointProperty.TargetPort).GetValueAsync(cancellationToken).ConfigureAwait(false), 77_ => await endpointReference.Property(property).GetValueAsync(cancellationToken).ConfigureAwait(false) 90var result = await ResolveInternalAsync(expr.ValueProviders[i]).ConfigureAwait(false); 106var value = await vp.GetValueAsync(cancellationToken).ConfigureAwait(false); 160var value = await ResolveInternalAsync(cs.Resource.ConnectionStringExpression).ConfigureAwait(false); 179IResourceWithConnectionString cs and not ConnectionStringParameterResource => await ResolveInternalAsync(cs.ConnectionStringExpression).ConfigureAwait(false), 194await resolver.ResolveInternalAsync(valueProvider).ConfigureAwait(false); 197return await resolver.ResolveInternalAsync(valueProvider).ConfigureAwait(false); 202return await ResolveWithContainerSourceAsync(valueProvider, containerHostName, sourceIsContainer, cancellationToken).ConfigureAwait(false);
ApplicationModel\ReferenceExpression.cs (1)
67args[i] = await ValueProviders[i].GetValueAsync(cancellationToken).ConfigureAwait(false);
ApplicationModel\ResourceExtensions.cs (1)
463return await task.ConfigureAwait(false);
Backchannel\AppHostRpcTarget.cs (1)
57var publishingActivity = await activityReporter.ActivityItemUpdated.Reader.ReadAsync(cancellationToken).ConfigureAwait(false);
Backchannel\BackchannelService.cs (1)
48var clientSocket = await serverSocket.AcceptAsync(stoppingToken).ConfigureAwait(false);
Cli\CliOrphanDetector.cs (1)
45} while (await periodic.WaitForNextTickAsync(stoppingToken).ConfigureAwait(false));
Dcp\DcpExecutor.cs (4)
1326IValueProvider valueProvider => await valueProvider.GetValueAsync(cancellationToken).ConfigureAwait(false), 1356IValueProvider valueProvider => await valueProvider.GetValueAsync(cancellationToken).ConfigureAwait(false), 1546}, resourceReference.DcpResourceName, cancellationToken).ConfigureAwait(false); 1660}, resourceName, cancellationToken).ConfigureAwait(false);
Dcp\DcpHost.cs (2)
248var acceptedSocket = await socket.AcceptAsync(_shutdownCts.Token).ConfigureAwait(false); 348var result = await reader.ReadAsync(CancellationToken.None).ConfigureAwait(false);
Dcp\KubernetesService.cs (3)
425}, cancellationToken).ConfigureAwait(false); 479}, cancellationToken).ConfigureAwait(false); 600}, cancellationToken).ConfigureAwait(false);
Dcp\ResourceLogSource.cs (1)
76var line = await sr.ReadLineAsync(cancellationToken).ConfigureAwait(false);
Orchestrator\ApplicationOrchestrator.cs (2)
65var connectionString = await resourceWithConnectionString.GetConnectionStringAsync(token).ConfigureAwait(false); 282var value = await valueProvider.GetValueAsync(cancellationToken).ConfigureAwait(false);
ResourceBuilderExtensions.cs (1)
892var urlValue = await url.GetValueAsync(c.CancellationToken).ConfigureAwait(false);
src\Shared\ChannelExtensions.cs (1)
36if (await channel.Reader.WaitToReadAsync(cancellationToken).ConfigureAwait(false))
Utils\PeriodicRestartAsyncEnumerable.cs (2)
39if (!await enumerator.MoveNextAsync().ConfigureAwait(false)) 95if (!await enumerator.MoveNextAsync().ConfigureAwait(false))
Aspire.Hosting.Azure (5)
Provisioning\BicepUtilities.cs (2)
54IValueProvider v => await v.GetValueAsync(cancellationToken).ConfigureAwait(false), 74IValueProvider v => await v.GetValueAsync(cancellationToken).ConfigureAwait(false),
Provisioning\Internal\DefaultUserPrincipalProvider.cs (1)
17var response = await credential.GetTokenAsync(new(["https://graph.windows.net/.default"]), cancellationToken).ConfigureAwait(false);
Provisioning\Provisioners\BicepProvisioner.cs (2)
31var currentCheckSum = await BicepUtilities.GetCurrentChecksumAsync(resource, section, cancellationToken).ConfigureAwait(false); 190await operation.WaitForCompletionAsync(cancellationToken).ConfigureAwait(false);
Aspire.Hosting.Azure.CosmosDB (1)
AzureCosmosDBExtensions.cs (1)
94var connectionString = await builder.Resource.ConnectionStringExpression.GetValueAsync(ct).ConfigureAwait(false);
Aspire.Hosting.Azure.Storage (3)
AzureStorageExtensions.cs (3)
141var connectionString = await builder.Resource.GetBlobConnectionString().GetValueAsync(ct).ConfigureAwait(false) ?? throw new DistributedApplicationException($"{nameof(ConnectionStringAvailableEvent)} was published for the '{builder.Resource.Name}' resource but the connection string was null."); 300connectionString = await resource.ConnectionStringExpression.GetValueAsync(ct).ConfigureAwait(false); 334connectionString = await resource.Parent.ConnectionStringExpression.GetValueAsync(ct).ConfigureAwait(false);
Aspire.Hosting.Garnet (1)
GarnetBuilderExtensions.cs (1)
114connectionString = await garnet.ConnectionStringExpression.GetValueAsync(ct).ConfigureAwait(false);
Aspire.Hosting.Kafka (1)
KafkaBuilderExtensions.cs (1)
43connectionString = await kafka.ConnectionStringExpression.GetValueAsync(ct).ConfigureAwait(false);
Aspire.Hosting.MongoDB (2)
MongoDBBuilderExtensions.cs (2)
64connectionString = await mongoDBContainer.ConnectionStringExpression.GetValueAsync(ct).ConfigureAwait(false); 115connectionString = await mongoDBDatabase.ConnectionStringExpression.GetValueAsync(ct).ConfigureAwait(false);
Aspire.Hosting.MySql (2)
MySqlBuilderExtensions.cs (2)
45connectionString = await resource.ConnectionStringExpression.GetValueAsync(ct).ConfigureAwait(false); 111connectionString = await mySqlDatabase.ConnectionStringExpression.GetValueAsync(ct).ConfigureAwait(false);
Aspire.Hosting.Nats (2)
NatsBuilderExtensions.cs (2)
62var connectionString = await nats.ConnectionStringExpression.GetValueAsync(ct).ConfigureAwait(false) 75Username = await nats.UserNameReference.GetValueAsync(ct).ConfigureAwait(false),
Aspire.Hosting.Oracle (1)
OracleDatabaseBuilderExtensions.cs (1)
45connectionString = await oracleDatabaseServer.ConnectionStringExpression.GetValueAsync(ct).ConfigureAwait(false);
Aspire.Hosting.PostgreSQL (2)
PostgresBuilderExtensions.cs (2)
58connectionString = await postgresServer.GetConnectionStringAsync(ct).ConfigureAwait(false); 154connectionString = await postgresDatabase.ConnectionStringExpression.GetValueAsync(ct).ConfigureAwait(false);
Aspire.Hosting.Qdrant (1)
QdrantBuilderExtensions.cs (1)
54var connectionString = await qdrant.ConnectionStringExpression.GetValueAsync(ct).ConfigureAwait(false)
Aspire.Hosting.RabbitMQ (1)
RabbitMQBuilderExtensions.cs (1)
47connectionString = await rabbitMq.ConnectionStringExpression.GetValueAsync(ct).ConfigureAwait(false);
Aspire.Hosting.Redis (1)
RedisBuilderExtensions.cs (1)
76connectionString = await redis.GetConnectionStringAsync(ct).ConfigureAwait(false);
Aspire.Hosting.SqlServer (2)
SqlServerBuilderExtensions.cs (2)
50connectionString = await sqlServer.GetConnectionStringAsync(ct).ConfigureAwait(false); 117connectionString = await sqlServerDatabase.ConnectionStringExpression.GetValueAsync(ct).ConfigureAwait(false);
Aspire.Hosting.Valkey (1)
ValkeyBuilderExtensions.cs (1)
127connectionString = await valkey.ConnectionStringExpression.GetValueAsync(ct).ConfigureAwait(false);
Aspire.Hosting.Yarp (1)
YarpResourceExtensions.cs (1)
66var contents = await yarpBuilder.Resource.JsonConfigGenerator.Build(ct).ConfigureAwait(false);
GenerateDocumentationAndConfigFiles (60)
src\Compilers\Core\Portable\Hashing\NonCryptographicHashAlgorithm.cs (1)
165int read = await stream.ReadAsync(buffer.AsMemory(), cancellationToken).ConfigureAwait(false);
src\Dependencies\Collections\Extensions\IEnumerableExtensions.cs (4)
483builder.Add(await selector(item).ConfigureAwait(false)); 498builder.Add(await selector(item, cancellationToken).ConfigureAwait(false)); 513builder.Add(await selector(item, arg, cancellationToken).ConfigureAwait(false)); 525builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
src\Dependencies\Collections\Extensions\ImmutableArrayExtensions.cs (3)
427builder[i] = await selector(array[i], cancellationToken).ConfigureAwait(false); 445builder[i] = await selector(array[i], arg, cancellationToken).ConfigureAwait(false); 471builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
src\Dependencies\Threading\AsyncBatchingWorkQueue`2.cs (1)
220return (ranToCompletion: true, await ProcessNextBatchAsync().ConfigureAwait(false));
src\Dependencies\Threading\ValueTaskExtensions.cs (2)
237_task.ConfigureAwait(_captureContext).GetAwaiter().OnCompleted(continuation); 247_task.ConfigureAwait(_captureContext).GetAwaiter().UnsafeOnCompleted(continuation);
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Utilities\IAsyncEnumerableExtensions.cs (1)
84while (await reader.WaitToReadAsync(cancellationToken).ConfigureAwait(false))
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Utilities\ProducerConsumer.cs (1)
47while (await reader.WaitToReadAsync(cancellationToken).ConfigureAwait(false))
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\AddImport\AddImportPlacementOptionsProviders.cs (1)
29var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeCleanup\CodeCleanupOptionsProviders.cs (1)
29var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeFixes\ForkingSyntaxEditorBasedCodeFixProvider.cs (1)
99changedRoot, cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeFixes\SyntaxEditorBasedCodeFixProvider.cs (1)
83var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeGeneration\AbstractCodeGenerationService.cs (2)
244var codeGenOptions = await oldDocument.GetCodeGenerationOptionsAsync(cancellationToken).ConfigureAwait(false); 256var addImportsOptions = await newDocument.GetAddImportPlacementOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeGeneration\CleanCodeGenerationOptions.cs (2)
42GenerationOptions = await document.GetCodeGenerationOptionsAsync(cancellationToken).ConfigureAwait(false), 43CleanupOptions = await document.GetCodeCleanupOptionsAsync(cancellationToken).ConfigureAwait(false)
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeGeneration\CodeGenerationOptionsProviders.cs (2)
36var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false); 44var options = await GetCodeGenerationOptionsAsync(document, cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeRefactorings\CodeRefactoringContextExtensions.cs (4)
46var parsedDocument = await ParsedDocument.CreateAsync(context.Document, context.CancellationToken).ConfigureAwait(false); 55var parsedDocument = await ParsedDocument.CreateAsync(context.Document, context.CancellationToken).ConfigureAwait(false); 61var parsedDocument = await ParsedDocument.CreateAsync(document, cancellationToken).ConfigureAwait(false); 84var parsedDocument = await ParsedDocument.CreateAsync(document, cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Editing\ImportAdderService.cs (5)
37var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 120var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 121var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 180var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 183var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Extensions\DocumentExtensions.cs (3)
132var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 136return await ReuseExistingSpeculativeModelAsync(document, node, cancellationToken).ConfigureAwait(false); 225var syntaxTree = await document.GetRequiredSyntaxTreeAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Formatting\DocumentFormattingOptionsProviders.cs (1)
24var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Formatting\LineFormattingOptionsProviders.cs (1)
19var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Formatting\SyntaxFormattingOptionsProviders.cs (1)
22var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\LanguageServices\InitializeParameter\AbstractInitializerParameterService.cs (2)
119var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 123var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\LanguageServices\RemoveUnnecessaryImports\AbstractRemoveUnnecessaryImportsService.cs (2)
27var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 34var currentModel = await current.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\NamingStyles\NamingStylePreferencesProviders.cs (1)
17var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Options\MemberDisplayOptions.cs (1)
52var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\SemanticModelReuse\SemanticModelWorkspaceServiceFactory.SemanticModelWorkspaceService.cs (2)
104return await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 159var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Simplification\AbstractSimplificationService.cs (6)
69var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 96var root = (TCompilationUnitSyntax)await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 107root = (TCompilationUnitSyntax)await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 165var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 236semanticModelForReduce = await newDocument.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 291var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Simplification\SimplifierOptionsProviders.cs (1)
22var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Utilities\ParsedDocument.cs (2)
33var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 34var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Utilities\SemanticDocument.cs (3)
20var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 21var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 22var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Utilities\SyntacticDocument.cs (2)
30var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 31var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
Metrics (12)
src\Dependencies\Collections\Extensions\IEnumerableExtensions.cs (4)
483builder.Add(await selector(item).ConfigureAwait(false)); 498builder.Add(await selector(item, cancellationToken).ConfigureAwait(false)); 513builder.Add(await selector(item, arg, cancellationToken).ConfigureAwait(false)); 525builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
src\Dependencies\Collections\Extensions\ImmutableArrayExtensions.cs (3)
427builder[i] = await selector(array[i], cancellationToken).ConfigureAwait(false); 445builder[i] = await selector(array[i], arg, cancellationToken).ConfigureAwait(false); 471builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
src\Dependencies\Threading\AsyncBatchingWorkQueue`2.cs (1)
220return (ranToCompletion: true, await ProcessNextBatchAsync().ConfigureAwait(false));
src\Dependencies\Threading\ValueTaskExtensions.cs (2)
237_task.ConfigureAwait(_captureContext).GetAwaiter().OnCompleted(continuation); 247_task.ConfigureAwait(_captureContext).GetAwaiter().UnsafeOnCompleted(continuation);
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Utilities\IAsyncEnumerableExtensions.cs (1)
84while (await reader.WaitToReadAsync(cancellationToken).ConfigureAwait(false))
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Utilities\ProducerConsumer.cs (1)
47while (await reader.WaitToReadAsync(cancellationToken).ConfigureAwait(false))
Metrics.Legacy (12)
src\Dependencies\Collections\Extensions\IEnumerableExtensions.cs (4)
483builder.Add(await selector(item).ConfigureAwait(false)); 498builder.Add(await selector(item, cancellationToken).ConfigureAwait(false)); 513builder.Add(await selector(item, arg, cancellationToken).ConfigureAwait(false)); 525builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
src\Dependencies\Collections\Extensions\ImmutableArrayExtensions.cs (3)
427builder[i] = await selector(array[i], cancellationToken).ConfigureAwait(false); 445builder[i] = await selector(array[i], arg, cancellationToken).ConfigureAwait(false); 471builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
src\Dependencies\Threading\AsyncBatchingWorkQueue`2.cs (1)
220return (ranToCompletion: true, await ProcessNextBatchAsync().ConfigureAwait(false));
src\Dependencies\Threading\ValueTaskExtensions.cs (2)
237_task.ConfigureAwait(_captureContext).GetAwaiter().OnCompleted(continuation); 247_task.ConfigureAwait(_captureContext).GetAwaiter().UnsafeOnCompleted(continuation);
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Utilities\IAsyncEnumerableExtensions.cs (1)
84while (await reader.WaitToReadAsync(cancellationToken).ConfigureAwait(false))
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Utilities\ProducerConsumer.cs (1)
47while (await reader.WaitToReadAsync(cancellationToken).ConfigureAwait(false))
Microsoft.AspNetCore.Http.Connections (1)
src\SignalR\common\Shared\PipeWriterStream.cs (1)
94var flushResult = await flushTask.ConfigureAwait(false);
Microsoft.AspNetCore.Http.Connections.Client (9)
Internal\LongPollingTransport.cs (1)
198var flushResult = await _application.Output.FlushAsync(cancellationToken).ConfigureAwait(false);
Internal\SendUtils.cs (1)
27var result = await application.Input.ReadAsync(cancellationToken).ConfigureAwait(false);
Internal\ServerSentEventsTransport.cs (1)
146var flushResult = await _application.Output.WriteAsync(item.Data, default).ConfigureAwait(false);
Internal\WebSocketsTransport.cs (5)
306_webSocket = await factory(context, cancellationToken).ConfigureAwait(false); 443var result = await socket.ReceiveAsync(Memory<byte>.Empty, _stopCts.Token).ConfigureAwait(false); 461var receiveResult = await socket.ReceiveAsync(memory, _stopCts.Token).ConfigureAwait(false); 489var flushResult = await _application.Output.FlushAsync().ConfigureAwait(false); 540var result = await _application.Input.ReadAsync().ConfigureAwait(false);
src\SignalR\common\Shared\PipeWriterStream.cs (1)
94var flushResult = await flushTask.ConfigureAwait(false);
Microsoft.AspNetCore.OutputCaching.StackExchangeRedis (8)
RedisOutputCacheStore.cs (8)
60await ConnectAsync(cancellationToken).ConfigureAwait(false); 105await ExecuteGarbageCollectionAsync(GetExpirationTimestamp(TimeSpan.Zero), _disposalCancellation.Token).ConfigureAwait(false); 128var cache = await ConnectAsync(CancellationToken.None).ConfigureAwait(false); 167var cache = await ConnectAsync(cancellationToken).ConfigureAwait(false); 192var cache = await ConnectAsync(cancellationToken).ConfigureAwait(false); 211var cache = await ConnectAsync(cancellationToken).ConfigureAwait(false); 226await destination.FlushAsync(cancellationToken).ConfigureAwait(false); 245var cache = await ConnectAsync(cancellationToken).ConfigureAwait(false);
Microsoft.AspNetCore.Server.Kestrel.Core (2)
Internal\Infrastructure\TransportManager.cs (2)
47var transport = await transportFactory.BindAsync(endPoint, cancellationToken).ConfigureAwait(false); 81var transport = await multiplexedTransportFactory.BindAsync(endPoint, features, cancellationToken).ConfigureAwait(false);
Microsoft.AspNetCore.SignalR.Client.Core (23)
HubConnection.cs (11)
495var connection = await _connectionFactory.ConnectAsync(_endPoint, cancellationToken).ConfigureAwait(false); 686while (await reader.WaitToReadAsync(cts.Token).ConfigureAwait(false)) 907while (await enumerator.MoveNextAsync().ConfigureAwait(false)) 941while (await reader.WaitToReadAsync(tokenSource.Token).ConfigureAwait(false)) 1215await connectionState.WriteAsync(hubMessage, cancellationToken).ConfigureAwait(false); 1221await connectionState.Connection.Transport.Output.FlushAsync(cancellationToken).ConfigureAwait(false); 1466else if (!await irq.StreamItem(streamItem.Item).ConfigureAwait(false)) 1499var sendHandshakeResult = await startingConnectionState.Connection.Transport.Output.FlushAsync(CancellationToken.None).ConfigureAwait(false); 1520var result = await input.ReadAsync(linkedToken).ConfigureAwait(false); 1618while (await invocationMessageChannelReader.WaitToReadAsync().ConfigureAwait(false)) 1640var result = await input.ReadAsync().ConfigureAwait(false);
HubConnectionExtensions.StreamAsChannelAsync.cs (2)
291while (await inputChannel.WaitToReadAsync().ConfigureAwait(false)) 297if (!await outputChannel.Writer.WaitToWriteAsync().ConfigureAwait(false))
Internal\InvocationRequest.cs (1)
141if (!await _channel.Writer.WaitToWriteAsync().ConfigureAwait(false))
src\SignalR\common\Shared\AsyncEnumerableAdapters.cs (2)
57while (await _channel.WaitToReadAsync(_cancellationToken).ConfigureAwait(false)) 235while (await ((ValueTask<bool>)_waitToReadAsyncMethodInfo.Invoke(_channelReader, _waitToReadArgs)!).ConfigureAwait(false))
src\SignalR\common\Shared\MessageBuffer.cs (6)
93while (await _timer.WaitForNextTickAsync().ConfigureAwait(false)) 110await _writer.FlushAsync().ConfigureAwait(false); 139while (await _waitForAck.Reader.WaitToReadAsync(cancellationToken).ConfigureAwait(false)) 181return await writeTask.ConfigureAwait(false); 280finalResult = await _writer.WriteAsync(item.HubMessage).ConfigureAwait(false); 288finalResult = await _writer.FlushAsync().ConfigureAwait(false);
src\SignalR\common\Shared\PipeWriterStream.cs (1)
94var flushResult = await flushTask.ConfigureAwait(false);
Microsoft.AspNetCore.SignalR.Core (8)
src\SignalR\common\Shared\AsyncEnumerableAdapters.cs (2)
57while (await _channel.WaitToReadAsync(_cancellationToken).ConfigureAwait(false)) 235while (await ((ValueTask<bool>)_waitToReadAsyncMethodInfo.Invoke(_channelReader, _waitToReadArgs)!).ConfigureAwait(false))
src\SignalR\common\Shared\MessageBuffer.cs (6)
93while (await _timer.WaitForNextTickAsync().ConfigureAwait(false)) 110await _writer.FlushAsync().ConfigureAwait(false); 139while (await _waitForAck.Reader.WaitToReadAsync(cancellationToken).ConfigureAwait(false)) 181return await writeTask.ConfigureAwait(false); 280finalResult = await _writer.WriteAsync(item.HubMessage).ConfigureAwait(false); 288finalResult = await _writer.FlushAsync().ConfigureAwait(false);
Microsoft.AspNetCore.WebUtilities (1)
HttpRequestStreamReader.cs (1)
490_bytesRead = await _stream.ReadAsync(_byteBuffer.AsMemory(0, _byteBufferSize)).ConfigureAwait(false);
Microsoft.Build.Tasks.Core (2)
NodePipeBase.cs (2)
167int headerBytesRead = await ReadAsync(_headerData, HeaderLength, cancellationToken).ConfigureAwait(false); 188int packetBytesRead = await ReadAsync(_readBuffer.GetBuffer(), packetLength, cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis (31)
DiagnosticAnalyzer\AnalyzerDriver.cs (13)
1595var optionalEvent = await CompilationEventQueue.TryDequeueAsync(cancellationToken).ConfigureAwait(false); 1634EventProcessedState eventProcessedState = await TryProcessEventCoreAsync(e, analysisScope, cancellationToken).ConfigureAwait(false); 1723return await TryProcessSymbolDeclaredAsync(symbolEvent, analysisScope, cancellationToken).ConfigureAwait(false); 1761await GetPerSymbolAnalyzerActionsAsync(symbol, analysisScope, cancellationToken).ConfigureAwait(false) : 2037var analyzerActions = await analyzerManager.GetAnalyzerActionsAsync(analyzer, analyzerExecutor, cancellationToken).ConfigureAwait(false); 2122var analyzerActions = await GetPerSymbolAnalyzerActionsAsync(symbol, analyzer, analysisScope.OriginalFilterFile?.SourceTree, analysisScope.OriginalFilterSpan, cancellationToken).ConfigureAwait(false); 2154return await getAllActionsAsync(this, symbol, analyzer, filterTree, filterSpan, cancellationToken).ConfigureAwait(false); 2162var allActions = await getAllActionsAsync(this, symbol, analyzer, filterTree, filterSpan, cancellationToken).ConfigureAwait(false); 2168var inheritedActions = await getInheritedActionsAsync(driver, symbol, analyzer, filterTree, filterSpan, cancellationToken).ConfigureAwait(false); 2171AnalyzerActions myActions = await getSymbolActionsCoreAsync(driver, symbol, analyzer, filterTree, filterSpan, cancellationToken).ConfigureAwait(false); 2186var containerActions = await driver.GetPerSymbolAnalyzerActionsAsync(symbol.ContainingSymbol, analyzer, filterTree, filterSpan, cancellationToken).ConfigureAwait(false); 2218return await driver.AnalyzerManager.GetPerSymbolAnalyzerActionsAsync(symbol, isGeneratedCodeSymbol, filterTree, filterSpan, analyzer, driver.AnalyzerExecutor, cancellationToken).ConfigureAwait(false); 2363var analyzerActions = await AnalyzerManager.GetAnalyzerActionsAsync(analyzer, AnalyzerExecutor, cancellationToken).ConfigureAwait(false);
DiagnosticAnalyzer\AnalyzerManager.cs (9)
65return await GetCompilationAnalysisScopeCoreAsync(sessionScope, analyzerExecutor, analyzerExecutionContext, cancellationToken).ConfigureAwait(false); 88return await GetCompilationAnalysisScopeCoreAsync(sessionScope, analyzerExecutor, analyzerExecutionContext, cancellationToken).ConfigureAwait(false); 138return await GetSessionAnalysisScopeCoreAsync(analyzerExecutor, analyzerExecutionContext, cancellationToken).ConfigureAwait(false); 159return await GetSessionAnalysisScopeCoreAsync(analyzerExecutor, analyzerExecutionContext, cancellationToken).ConfigureAwait(false); 171var sessionScope = await GetSessionAnalysisScopeAsync(analyzer, analyzerExecutor, cancellationToken).ConfigureAwait(false); 174var compilationScope = await GetCompilationAnalysisScopeAsync(sessionScope, analyzerExecutor, cancellationToken).ConfigureAwait(false); 195var analyzerActions = await GetAnalyzerActionsAsync(analyzer, analyzerExecutor, cancellationToken).ConfigureAwait(false); 236var sessionScope = await GetSessionAnalysisScopeAsync(analyzer, analyzerExecutor, cancellationToken).ConfigureAwait(false); 246var sessionScope = await GetSessionAnalysisScopeAsync(analyzer, analyzerExecutor, cancellationToken).ConfigureAwait(false);
DiagnosticAnalyzer\AsyncQueue.cs (1)
247var result = await optionalResult.ConfigureAwait(false);
Hashing\NonCryptographicHashAlgorithm.cs (1)
165int read = await stream.ReadAsync(buffer.AsMemory(), cancellationToken).ConfigureAwait(false);
src\Dependencies\Collections\Extensions\IEnumerableExtensions.cs (4)
483builder.Add(await selector(item).ConfigureAwait(false)); 498builder.Add(await selector(item, cancellationToken).ConfigureAwait(false)); 513builder.Add(await selector(item, arg, cancellationToken).ConfigureAwait(false)); 525builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
src\Dependencies\Collections\Extensions\ImmutableArrayExtensions.cs (3)
427builder[i] = await selector(array[i], cancellationToken).ConfigureAwait(false); 445builder[i] = await selector(array[i], arg, cancellationToken).ConfigureAwait(false); 471builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
Microsoft.CodeAnalysis.Analyzers (71)
FixAnalyzers\FixerWithFixAllAnalyzer.Fixer.cs (2)
37SyntaxNode root = await context.Document.GetRequiredSyntaxRootAsync(context.CancellationToken).ConfigureAwait(false); 61var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
MetaAnalyzers\Fixers\ApplyDiagnosticAnalyzerAttributeFix.cs (1)
21SyntaxNode root = await context.Document.GetRequiredSyntaxRootAsync(context.CancellationToken).ConfigureAwait(false);
MetaAnalyzers\Fixers\CompareSymbolsCorrectlyFix.cs (4)
66var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 67var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 81var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 82var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
MetaAnalyzers\Fixers\ConfigureGeneratedCodeAnalysisFix.cs (2)
44var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 51var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
MetaAnalyzers\Fixers\DefineDiagnosticDescriptorArgumentsCorrectlyFix.cs (2)
39var root = await context.Document.GetRequiredSyntaxRootAsync(context.CancellationToken).ConfigureAwait(false); 47var semanticModel = await context.Document.GetRequiredSemanticModelAsync(context.CancellationToken).ConfigureAwait(false);
MetaAnalyzers\Fixers\EnableConcurrentExecutionFix.cs (1)
43var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Dependencies\Collections\Extensions\IEnumerableExtensions.cs (4)
483builder.Add(await selector(item).ConfigureAwait(false)); 498builder.Add(await selector(item, cancellationToken).ConfigureAwait(false)); 513builder.Add(await selector(item, arg, cancellationToken).ConfigureAwait(false)); 525builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
src\Dependencies\Collections\Extensions\ImmutableArrayExtensions.cs (3)
427builder[i] = await selector(array[i], cancellationToken).ConfigureAwait(false); 445builder[i] = await selector(array[i], arg, cancellationToken).ConfigureAwait(false); 471builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
src\Dependencies\Threading\AsyncBatchingWorkQueue`2.cs (1)
220return (ranToCompletion: true, await ProcessNextBatchAsync().ConfigureAwait(false));
src\Dependencies\Threading\ValueTaskExtensions.cs (2)
237_task.ConfigureAwait(_captureContext).GetAwaiter().OnCompleted(continuation); 247_task.ConfigureAwait(_captureContext).GetAwaiter().UnsafeOnCompleted(continuation);
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Utilities\IAsyncEnumerableExtensions.cs (1)
84while (await reader.WaitToReadAsync(cancellationToken).ConfigureAwait(false))
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Utilities\ProducerConsumer.cs (1)
47while (await reader.WaitToReadAsync(cancellationToken).ConfigureAwait(false))
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\AddImport\AddImportPlacementOptionsProviders.cs (1)
29var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeCleanup\CodeCleanupOptionsProviders.cs (1)
29var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeFixes\ForkingSyntaxEditorBasedCodeFixProvider.cs (1)
99changedRoot, cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeFixes\SyntaxEditorBasedCodeFixProvider.cs (1)
83var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeGeneration\AbstractCodeGenerationService.cs (2)
244var codeGenOptions = await oldDocument.GetCodeGenerationOptionsAsync(cancellationToken).ConfigureAwait(false); 256var addImportsOptions = await newDocument.GetAddImportPlacementOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeGeneration\CleanCodeGenerationOptions.cs (2)
42GenerationOptions = await document.GetCodeGenerationOptionsAsync(cancellationToken).ConfigureAwait(false), 43CleanupOptions = await document.GetCodeCleanupOptionsAsync(cancellationToken).ConfigureAwait(false)
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeGeneration\CodeGenerationOptionsProviders.cs (2)
36var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false); 44var options = await GetCodeGenerationOptionsAsync(document, cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeRefactorings\CodeRefactoringContextExtensions.cs (4)
46var parsedDocument = await ParsedDocument.CreateAsync(context.Document, context.CancellationToken).ConfigureAwait(false); 55var parsedDocument = await ParsedDocument.CreateAsync(context.Document, context.CancellationToken).ConfigureAwait(false); 61var parsedDocument = await ParsedDocument.CreateAsync(document, cancellationToken).ConfigureAwait(false); 84var parsedDocument = await ParsedDocument.CreateAsync(document, cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Editing\ImportAdderService.cs (5)
37var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 120var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 121var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 180var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 183var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Extensions\DocumentExtensions.cs (3)
132var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 136return await ReuseExistingSpeculativeModelAsync(document, node, cancellationToken).ConfigureAwait(false); 225var syntaxTree = await document.GetRequiredSyntaxTreeAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Formatting\DocumentFormattingOptionsProviders.cs (1)
24var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Formatting\LineFormattingOptionsProviders.cs (1)
19var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Formatting\SyntaxFormattingOptionsProviders.cs (1)
22var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\LanguageServices\InitializeParameter\AbstractInitializerParameterService.cs (2)
119var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 123var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\LanguageServices\RemoveUnnecessaryImports\AbstractRemoveUnnecessaryImportsService.cs (2)
27var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 34var currentModel = await current.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\NamingStyles\NamingStylePreferencesProviders.cs (1)
17var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Options\MemberDisplayOptions.cs (1)
52var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\SemanticModelReuse\SemanticModelWorkspaceServiceFactory.SemanticModelWorkspaceService.cs (2)
104return await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 159var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Simplification\AbstractSimplificationService.cs (6)
69var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 96var root = (TCompilationUnitSyntax)await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 107root = (TCompilationUnitSyntax)await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 165var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 236semanticModelForReduce = await newDocument.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 291var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Simplification\SimplifierOptionsProviders.cs (1)
22var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Utilities\ParsedDocument.cs (2)
33var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 34var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Utilities\SemanticDocument.cs (3)
20var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 21var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 22var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Utilities\SyntacticDocument.cs (2)
30var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 31var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.AnalyzerUtilities (12)
src\Dependencies\Collections\Extensions\IEnumerableExtensions.cs (4)
483builder.Add(await selector(item).ConfigureAwait(false)); 498builder.Add(await selector(item, cancellationToken).ConfigureAwait(false)); 513builder.Add(await selector(item, arg, cancellationToken).ConfigureAwait(false)); 525builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
src\Dependencies\Collections\Extensions\ImmutableArrayExtensions.cs (3)
427builder[i] = await selector(array[i], cancellationToken).ConfigureAwait(false); 445builder[i] = await selector(array[i], arg, cancellationToken).ConfigureAwait(false); 471builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
src\Dependencies\Threading\AsyncBatchingWorkQueue`2.cs (1)
220return (ranToCompletion: true, await ProcessNextBatchAsync().ConfigureAwait(false));
src\Dependencies\Threading\ValueTaskExtensions.cs (2)
237_task.ConfigureAwait(_captureContext).GetAwaiter().OnCompleted(continuation); 247_task.ConfigureAwait(_captureContext).GetAwaiter().UnsafeOnCompleted(continuation);
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Utilities\IAsyncEnumerableExtensions.cs (1)
84while (await reader.WaitToReadAsync(cancellationToken).ConfigureAwait(false))
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Utilities\ProducerConsumer.cs (1)
47while (await reader.WaitToReadAsync(cancellationToken).ConfigureAwait(false))
Microsoft.CodeAnalysis.BannedApiAnalyzers (59)
src\Dependencies\Collections\Extensions\IEnumerableExtensions.cs (4)
483builder.Add(await selector(item).ConfigureAwait(false)); 498builder.Add(await selector(item, cancellationToken).ConfigureAwait(false)); 513builder.Add(await selector(item, arg, cancellationToken).ConfigureAwait(false)); 525builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
src\Dependencies\Collections\Extensions\ImmutableArrayExtensions.cs (3)
427builder[i] = await selector(array[i], cancellationToken).ConfigureAwait(false); 445builder[i] = await selector(array[i], arg, cancellationToken).ConfigureAwait(false); 471builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
src\Dependencies\Threading\AsyncBatchingWorkQueue`2.cs (1)
220return (ranToCompletion: true, await ProcessNextBatchAsync().ConfigureAwait(false));
src\Dependencies\Threading\ValueTaskExtensions.cs (2)
237_task.ConfigureAwait(_captureContext).GetAwaiter().OnCompleted(continuation); 247_task.ConfigureAwait(_captureContext).GetAwaiter().UnsafeOnCompleted(continuation);
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Utilities\IAsyncEnumerableExtensions.cs (1)
84while (await reader.WaitToReadAsync(cancellationToken).ConfigureAwait(false))
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Utilities\ProducerConsumer.cs (1)
47while (await reader.WaitToReadAsync(cancellationToken).ConfigureAwait(false))
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\AddImport\AddImportPlacementOptionsProviders.cs (1)
29var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeCleanup\CodeCleanupOptionsProviders.cs (1)
29var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeFixes\ForkingSyntaxEditorBasedCodeFixProvider.cs (1)
99changedRoot, cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeFixes\SyntaxEditorBasedCodeFixProvider.cs (1)
83var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeGeneration\AbstractCodeGenerationService.cs (2)
244var codeGenOptions = await oldDocument.GetCodeGenerationOptionsAsync(cancellationToken).ConfigureAwait(false); 256var addImportsOptions = await newDocument.GetAddImportPlacementOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeGeneration\CleanCodeGenerationOptions.cs (2)
42GenerationOptions = await document.GetCodeGenerationOptionsAsync(cancellationToken).ConfigureAwait(false), 43CleanupOptions = await document.GetCodeCleanupOptionsAsync(cancellationToken).ConfigureAwait(false)
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeGeneration\CodeGenerationOptionsProviders.cs (2)
36var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false); 44var options = await GetCodeGenerationOptionsAsync(document, cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeRefactorings\CodeRefactoringContextExtensions.cs (4)
46var parsedDocument = await ParsedDocument.CreateAsync(context.Document, context.CancellationToken).ConfigureAwait(false); 55var parsedDocument = await ParsedDocument.CreateAsync(context.Document, context.CancellationToken).ConfigureAwait(false); 61var parsedDocument = await ParsedDocument.CreateAsync(document, cancellationToken).ConfigureAwait(false); 84var parsedDocument = await ParsedDocument.CreateAsync(document, cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Editing\ImportAdderService.cs (5)
37var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 120var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 121var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 180var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 183var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Extensions\DocumentExtensions.cs (3)
132var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 136return await ReuseExistingSpeculativeModelAsync(document, node, cancellationToken).ConfigureAwait(false); 225var syntaxTree = await document.GetRequiredSyntaxTreeAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Formatting\DocumentFormattingOptionsProviders.cs (1)
24var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Formatting\LineFormattingOptionsProviders.cs (1)
19var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Formatting\SyntaxFormattingOptionsProviders.cs (1)
22var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\LanguageServices\InitializeParameter\AbstractInitializerParameterService.cs (2)
119var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 123var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\LanguageServices\RemoveUnnecessaryImports\AbstractRemoveUnnecessaryImportsService.cs (2)
27var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 34var currentModel = await current.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\NamingStyles\NamingStylePreferencesProviders.cs (1)
17var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Options\MemberDisplayOptions.cs (1)
52var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\SemanticModelReuse\SemanticModelWorkspaceServiceFactory.SemanticModelWorkspaceService.cs (2)
104return await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 159var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Simplification\AbstractSimplificationService.cs (6)
69var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 96var root = (TCompilationUnitSyntax)await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 107root = (TCompilationUnitSyntax)await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 165var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 236semanticModelForReduce = await newDocument.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 291var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Simplification\SimplifierOptionsProviders.cs (1)
22var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Utilities\ParsedDocument.cs (2)
33var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 34var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Utilities\SemanticDocument.cs (3)
20var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 21var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 22var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Utilities\SyntacticDocument.cs (2)
30var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 31var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.CodeStyle (12)
src\Dependencies\Collections\Extensions\IEnumerableExtensions.cs (4)
483builder.Add(await selector(item).ConfigureAwait(false)); 498builder.Add(await selector(item, cancellationToken).ConfigureAwait(false)); 513builder.Add(await selector(item, arg, cancellationToken).ConfigureAwait(false)); 525builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
src\Dependencies\Collections\Extensions\ImmutableArrayExtensions.cs (3)
427builder[i] = await selector(array[i], cancellationToken).ConfigureAwait(false); 445builder[i] = await selector(array[i], arg, cancellationToken).ConfigureAwait(false); 471builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
src\Dependencies\Threading\AsyncBatchingWorkQueue`2.cs (1)
220return (ranToCompletion: true, await ProcessNextBatchAsync().ConfigureAwait(false));
src\Dependencies\Threading\ValueTaskExtensions.cs (2)
237_task.ConfigureAwait(_captureContext).GetAwaiter().OnCompleted(continuation); 247_task.ConfigureAwait(_captureContext).GetAwaiter().UnsafeOnCompleted(continuation);
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Utilities\IAsyncEnumerableExtensions.cs (1)
84while (await reader.WaitToReadAsync(cancellationToken).ConfigureAwait(false))
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Utilities\ProducerConsumer.cs (1)
47while (await reader.WaitToReadAsync(cancellationToken).ConfigureAwait(false))
Microsoft.CodeAnalysis.CodeStyle.Fixes (192)
src\Analyzers\Core\CodeFixes\AddAccessibilityModifiers\AbstractAddAccessibilityModifiersCodeFixProvider.cs (1)
45var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\AddAnonymousTypeMemberName\AbstractAddAnonymousTypeMemberNameCodeFixProvider.cs (2)
56var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 90var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\AddExplicitCast\AbstractAddExplicitCastCodeFixProvider.cs (3)
73var root = await document.GetRequiredSyntaxRootAsync(context.CancellationToken).ConfigureAwait(false); 74var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 219var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\AddObsoleteAttribute\AbstractAddObsoleteAttributeCodeFixProvider.cs (2)
43var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 79var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\AddParameter\AbstractAddParameterCodeFixProvider.cs (4)
68var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 71var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 405var semanticModel = await invocationDocument.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 423var semanticModel = await invocationDocument.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\AddParameter\AddParameterService.cs (2)
113var syntaxRoot = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 183var rewrittenSyntaxRoot = await rewrittenDocument.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\AliasAmbiguousType\AbstractAliasAmbiguousTypeCodeFixProvider.cs (3)
34var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 41var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 50var placementOption = await document.GetAddImportPlacementOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\AnalyzerOptionsProviders.cs (1)
16var syntaxTree = await document.GetRequiredSyntaxTreeAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\ConflictMarkerResolution\AbstractConflictMarkerCodeFixProvider.cs (5)
74var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 75var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 319var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 405var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 406var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\ConvertToAsync\AbstractConvertToAsyncCodeFixProvider.cs (2)
23var root = await context.Document.GetRequiredSyntaxRootAsync(context.CancellationToken).ConfigureAwait(false); 54var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\ConvertTypeOfToNameOf\AbstractConvertTypeOfToNameOfCodeFixProvider.cs (1)
38var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\DocumentationComments\AbstractAddDocCommentNodesCodeFixProvider.cs (2)
31var root = await context.Document.GetRequiredSyntaxRootAsync(context.CancellationToken).ConfigureAwait(false); 60var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\DocumentationComments\AbstractRemoveDocCommentNodeCodeFixProvider.cs (2)
35var root = await context.Document.GetRequiredSyntaxRootAsync(context.CancellationToken).ConfigureAwait(false); 61var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\FileHeaders\AbstractFileHeaderCodeFixProvider.cs (2)
50var options = await document.GetLineFormattingOptionsAsync(cancellationToken).ConfigureAwait(false); 59var tree = await document.GetRequiredSyntaxTreeAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\ForEachCast\AbstractForEachCastCodeFixProvider.cs (1)
45var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\Formatting\FormattingCodeFixProvider.cs (4)
72var root = await context.Document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 73var text = await context.Document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 82var formattingOptions = await context.Document.GetSyntaxFormattingOptionsAsync(SyntaxFormatting, cancellationToken).ConfigureAwait(false); 90var formattingOptions = await document.GetSyntaxFormattingOptionsAsync(SyntaxFormatting, cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\GenerateConstructor\AbstractGenerateConstructorService.State.cs (9)
87if (!(await TryInitializeConstructorInitializerGenerationAsync(node, cancellationToken).ConfigureAwait(false))) 92if (!(await TryInitializeSimpleNameGenerationAsync(node, cancellationToken).ConfigureAwait(false))) 97if (!(await TryInitializeImplicitObjectCreationAsync(node, cancellationToken).ConfigureAwait(false))) 306return await TryDetermineTypeToGenerateInAsync(typeToGenerateIn, cancellationToken).ConfigureAwait(false); 323return await TryDetermineTypeToGenerateInAsync(typeToGenerateIn, cancellationToken).ConfigureAwait(false); 356return await TryDetermineTypeToGenerateInAsync(typeToGenerateIn, cancellationToken).ConfigureAwait(false); 397var definition = await SymbolFinderInternal.FindSourceDefinitionAsync(original, _document.Project.Solution, cancellationToken).ConfigureAwait(false); 464var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 482var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\GenerateDefaultConstructors\AbstractGenerateDefaultConstructorCodeFixProvider.cs (1)
28var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\GenerateEnumMember\AbstractGenerateEnumMemberService.State.cs (2)
34return await state.TryInitializeAsync(service, document, node, cancellationToken).ConfigureAwait(false) ? state : null; 67var sourceType = (await SymbolFinderInternal.FindSourceDefinitionAsync(TypeToGenerateIn, document.Project.Solution, cancellationToken).ConfigureAwait(false)) as INamedTypeSymbol;
src\Analyzers\Core\CodeFixes\GenerateMember\AbstractGenerateMemberCodeFixProvider.cs (1)
41var root = await document.GetRequiredSyntaxRootAsync(context.CancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\GenerateParameterizedMember\AbstractGenerateConversionService.cs (1)
41return await GetActionsAsync(document, state, cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\GenerateParameterizedMember\AbstractGenerateDeconstructMethodService.cs (1)
36return state != null ? await GetActionsAsync(document, state, cancellationToken).ConfigureAwait(false) : [];
src\Analyzers\Core\CodeFixes\GenerateParameterizedMember\AbstractGenerateMethodService.cs (1)
42return await GetActionsAsync(document, state, cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\GenerateParameterizedMember\AbstractGenerateParameterizedMemberService.CodeAction.cs (2)
68var property = await _state.SignatureInfo.GeneratePropertyAsync(syntaxFactory, _isAbstract, _state.IsWrittenTo, cancellationToken).ConfigureAwait(false); 84var method = await _state.SignatureInfo.GenerateMethodAsync(syntaxFactory, _isAbstract, cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\GenerateParameterizedMember\AbstractGenerateParameterizedMemberService.cs (1)
59var returnType = await state.SignatureInfo.DetermineReturnTypeAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\GenerateParameterizedMember\AbstractGenerateParameterizedMemberService.SignatureInfo.cs (5)
80type: await DetermineReturnTypeAsync(cancellationToken).ConfigureAwait(false), 84parameters: await DetermineParametersAsync(cancellationToken).ConfigureAwait(false), 94var parameters = await DetermineParametersAsync(cancellationToken).ConfigureAwait(false); 95var returnType = await DetermineReturnTypeAsync(cancellationToken).ConfigureAwait(false); 154Document.Project, typeSymbol, compilation, availableTypeParameterNames, cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\GenerateParameterizedMember\AbstractGenerateParameterizedMemberService.State.cs (2)
61TypeToGenerateIn = await SymbolFinderInternal.FindSourceDefinitionAsync(TypeToGenerateIn, document.Project.Solution, cancellationToken).ConfigureAwait(false) as INamedTypeSymbol; 90var generatedMethod = await SignatureInfo.GenerateMethodAsync(syntaxFactory, false, cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\GenerateParameterizedMember\TypeParameterSubstitution.cs (2)
78var commonDerivedType = await DetermineCommonDerivedTypeAsync(symbol).ConfigureAwait(false); 113_project, commonType, _compilation, _availableTypeParameterNames, _cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\GenerateVariable\AbstractGenerateVariableService.cs (1)
41var state = await State.GenerateAsync((TService)this, semanticDocument, node, cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\GenerateVariable\AbstractGenerateVariableService.GenerateLocalCodeAction.cs (2)
46var semanticModel = await _document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 64var info = await _document.GetCodeGenerationInfoAsync(context, cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\GenerateVariable\AbstractGenerateVariableService.State.cs (1)
80return await state.TryInitializeAsync(interfaceNode, cancellationToken).ConfigureAwait(false) ? state : null;
src\Analyzers\Core\CodeFixes\ImplementAbstractClass\AbstractImplementAbstractClassCodeFixProvider.cs (1)
28var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\ImplementAbstractClass\ImplementAbstractClassData.cs (4)
43var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 65var options = await document.GetImplementTypeOptionsAsync(cancellationToken).ConfigureAwait(false); 106var info = await _document.GetCodeGenerationInfoAsync(context, cancellationToken).ConfigureAwait(false); 114var root = await _document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\ImplementInterface\AbstractImplementInterfaceCodeFixProvider.cs (2)
36var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 42var options = await document.GetImplementTypeOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\ImplementInterface\AbstractImplementInterfaceService.cs (2)
47var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 64var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\ImplementInterface\ImplementInterfaceGenerator.cs (1)
74var tree = await this.Document.GetRequiredSyntaxTreeAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\ImplementInterface\ImplementInterfaceGenerator_DisposePattern.cs (4)
60var rootWithCoreMembers = await docWithCoreMembers.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 70var info = await document.GetCodeGenerationInfoAsync(context, cancellationToken).ConfigureAwait(false); 91var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 236var options = await document.GetSyntaxFormattingOptionsAsync(syntaxFormatting, cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\ImplementType\ImplementTypeOptions.cs (1)
79var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\Iterator\AbstractIteratorCodeFixProvider.cs (1)
21var root = await context.Document.GetRequiredSyntaxRootAsync(context.CancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\MakeFieldReadonly\AbstractMakeFieldReadonlyCodeFixProvider.cs (2)
44var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 75var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\MakeMethodAsynchronous\AbstractMakeMethodAsynchronousCodeFixProvider.cs (5)
45var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 114var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 172var newRoot = await newDocument.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 175var semanticModel = await newDocument.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 193var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\MakeMethodSynchronous\AbstractMakeMethodSynchronousCodeFixProvider.cs (6)
57var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 88var semanticModel = await newDocument.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 106var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 122var syntaxRoot = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 126var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 175var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\MakeTypePartial\AbstractMakeTypePartialCodeFixProvider.cs (1)
32var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\Naming\NamingExtensions.cs (1)
37var options = await document.GetNamingStylePreferencesAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\NamingStyle\NamingStyleCodeFixProvider.cs (2)
57var root = await document.GetRequiredSyntaxRootAsync(context.CancellationToken).ConfigureAwait(false); 73var model = await document.GetRequiredSemanticModelAsync(context.CancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\NewLines\ConsecutiveStatementPlacement\ConsecutiveStatementPlacementCodeFixProvider.cs (2)
46var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 47var options = await document.GetLineFormattingOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\NewLines\MultipleBlankLines\AbstractMultipleBlankLinesCodeFixProvider.cs (1)
48var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\OrderModifiers\AbstractOrderModifiersCodeFixProvider.cs (2)
40var syntaxTree = await context.Document.GetRequiredSyntaxTreeAsync(context.CancellationToken).ConfigureAwait(false); 52var options = await document.GetAnalyzerOptionsProviderAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\PopulateSwitch\AbstractPopulateSwitchCodeFixProvider.cs (1)
146var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\RemoveAsyncModifier\AbstractRemoveAsyncModifierCodeFixProvider.cs (2)
44var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 69var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\RemoveRedundantEquality\RemoveRedundantEqualityCodeFixProvider.cs (2)
36var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 41var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\RemoveUnnecessaryImports\AbstractRemoveUnnecessaryImportsCodeFixProvider.cs (1)
57var newRoot = await newDocument.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\RemoveUnnecessarySuppressions\RemoveUnnecessaryAttributeSuppressionsCodeFixProvider.cs (1)
28var root = await context.Document.GetRequiredSyntaxRootAsync(context.CancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\RemoveUnnecessarySuppressions\RemoveUnnecessaryPragmaSuppressionsCodeFixProvider.cs (1)
32var root = await context.Document.GetRequiredSyntaxRootAsync(context.CancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\RemoveUnusedMembers\AbstractRemoveUnusedMembersCodeFixProvider.cs (1)
48var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\RemoveUnusedParametersAndValues\AbstractRemoveUnusedValuesCodeFixProvider.cs (9)
164var root = await context.Document.GetRequiredSyntaxRootAsync(context.CancellationToken).ConfigureAwait(false); 278var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 286var formattingOptions = await document.GetSyntaxFormattingOptionsAsync(SyntaxFormatting, cancellationToken).ConfigureAwait(false); 298var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 301var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 784var newRoot = await newDocument.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 844var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 886root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 919var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\SimplifyInterpolation\AbstractSimplifyInterpolationCodeFixProvider.cs (1)
50var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\UnsealClass\AbstractUnsealClassCodeFixProvider.cs (4)
34var syntaxRoot = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 35var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 43type, document.Project.Solution, cancellationToken).ConfigureAwait(false); 64var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\UpdateLegacySuppressions\UpdateLegacySuppressionsCodeFixProvider.cs (1)
29var root = await context.Document.GetRequiredSyntaxRootAsync(context.CancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\UseCoalesceExpression\AbstractUseCoalesceExpressionForIfNullStatementCheckCodeFixProvider.cs (1)
36var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\UseCoalesceExpression\UseCoalesceExpressionForNullableTernaryConditionalCheckCodeFixProvider.cs (1)
40var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\UseCoalesceExpression\UseCoalesceExpressionForTernaryConditionalCheckCodeFixProvider.cs (1)
41var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\UseCollectionInitializer\AbstractUseCollectionInitializerCodeFixProvider.cs (1)
75var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\UseConditionalExpression\AbstractUseConditionalExpressionCodeFixProvider.cs (4)
48var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 50var formattingOptions = await document.GetSyntaxFormattingOptionsAsync(SyntaxFormatting, cancellationToken).ConfigureAwait(false); 92var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 148var sourceText = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\UseConditionalExpression\ForAssignment\AbstractUseConditionalExpressionForAssignmentCodeFixProvider.cs (1)
67var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\UseConditionalExpression\ForReturn\AbstractUseConditionalExpressionForReturnCodeFixProvider.cs (1)
54var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\UseNullPropagation\AbstractUseNullPropagationCodeFixProvider.cs (1)
80var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\UseObjectInitializer\AbstractUseObjectInitializerCodeFixProvider.cs (3)
71var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 72var currentRoot = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 85this.SyntaxFormatting, cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\UseSystemHashCode\UseSystemHashCodeCodeFixProvider.cs (1)
46var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\AddImport\AddImportPlacementOptionsProviders.cs (1)
29var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeCleanup\CodeCleanupOptionsProviders.cs (1)
29var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeFixes\SyntaxEditorBasedCodeFixProvider.cs (1)
83var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeGeneration\AbstractCodeGenerationService.cs (2)
244var codeGenOptions = await oldDocument.GetCodeGenerationOptionsAsync(cancellationToken).ConfigureAwait(false); 256var addImportsOptions = await newDocument.GetAddImportPlacementOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeGeneration\CleanCodeGenerationOptions.cs (2)
42GenerationOptions = await document.GetCodeGenerationOptionsAsync(cancellationToken).ConfigureAwait(false), 43CleanupOptions = await document.GetCodeCleanupOptionsAsync(cancellationToken).ConfigureAwait(false)
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeGeneration\CodeGenerationOptionsProviders.cs (2)
36var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false); 44var options = await GetCodeGenerationOptionsAsync(document, cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeRefactorings\CodeRefactoringContextExtensions.cs (4)
46var parsedDocument = await ParsedDocument.CreateAsync(context.Document, context.CancellationToken).ConfigureAwait(false); 55var parsedDocument = await ParsedDocument.CreateAsync(context.Document, context.CancellationToken).ConfigureAwait(false); 61var parsedDocument = await ParsedDocument.CreateAsync(document, cancellationToken).ConfigureAwait(false); 84var parsedDocument = await ParsedDocument.CreateAsync(document, cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Editing\ImportAdderService.cs (5)
37var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 120var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 121var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 180var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 183var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Extensions\DocumentExtensions.cs (3)
132var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 136return await ReuseExistingSpeculativeModelAsync(document, node, cancellationToken).ConfigureAwait(false); 225var syntaxTree = await document.GetRequiredSyntaxTreeAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Formatting\DocumentFormattingOptionsProviders.cs (1)
24var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Formatting\LineFormattingOptionsProviders.cs (1)
19var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Formatting\SyntaxFormattingOptionsProviders.cs (1)
22var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\LanguageServices\InitializeParameter\AbstractInitializerParameterService.cs (2)
119var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 123var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\LanguageServices\RemoveUnnecessaryImports\AbstractRemoveUnnecessaryImportsService.cs (2)
27var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 34var currentModel = await current.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\NamingStyles\NamingStylePreferencesProviders.cs (1)
17var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Options\MemberDisplayOptions.cs (1)
52var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\SemanticModelReuse\SemanticModelWorkspaceServiceFactory.SemanticModelWorkspaceService.cs (2)
104return await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 159var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Simplification\AbstractSimplificationService.cs (6)
69var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 96var root = (TCompilationUnitSyntax)await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 107root = (TCompilationUnitSyntax)await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 165var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 236semanticModelForReduce = await newDocument.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 291var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Simplification\SimplifierOptionsProviders.cs (1)
22var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Utilities\ParsedDocument.cs (2)
33var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 34var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Utilities\SemanticDocument.cs (3)
20var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 21var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 22var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Utilities\SyntacticDocument.cs (2)
30var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 31var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.Collections.Package (7)
Extensions\IEnumerableExtensions.cs (4)
483builder.Add(await selector(item).ConfigureAwait(false)); 498builder.Add(await selector(item, cancellationToken).ConfigureAwait(false)); 513builder.Add(await selector(item, arg, cancellationToken).ConfigureAwait(false)); 525builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
Extensions\ImmutableArrayExtensions.cs (3)
427builder[i] = await selector(array[i], cancellationToken).ConfigureAwait(false); 445builder[i] = await selector(array[i], arg, cancellationToken).ConfigureAwait(false); 471builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
Microsoft.CodeAnalysis.CSharp.CodeStyle.Fixes (5)
src\Analyzers\CSharp\CodeFixes\ConvertNamespace\ConvertNamespaceCodeFixProvider.cs (1)
58var options = await document.GetCSharpSyntaxFormattingOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\CSharp\CodeFixes\InlineDeclaration\CSharpInlineDeclarationCodeFixProvider.cs (1)
49var options = await document.GetCSharpSimplifierOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\CSharp\CodeFixes\NewLines\EmbeddedStatementPlacement\EmbeddedStatementPlacementCodeFixProvider.cs (1)
51var options = await document.GetCSharpSyntaxFormattingOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\CSharp\CodeFixes\UseCollectionExpression\CSharpCollectionExpressionRewriter.cs (1)
50var formattingOptions = await workspaceDocument.GetCSharpSyntaxFormattingOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\CSharp\CodeFixes\UsePrimaryConstructor\CSharpUsePrimaryConstructorCodeFixProvider.cs (1)
129var removedMembers = await RemoveMembersAsync().ConfigureAwait(false);
Microsoft.CodeAnalysis.CSharp.Features (26)
BraceMatching\BlockCommentBraceMatcher.cs (1)
32var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
CodeRefactorings\InlineTemporary\InlineTemporaryCodeRefactoringProvider.cs (1)
435var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Completion\CompletionProviders\CrefCompletionProvider.cs (1)
76var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Completion\CompletionProviders\ExplicitInterfaceMemberCompletionProvider.ItemGetter.cs (2)
53var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 124var text = await Document.GetValueTextAsync(CancellationToken).ConfigureAwait(false);
Completion\CompletionProviders\ExternAliasCompletionProvider.cs (1)
80var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Completion\CompletionProviders\NamedParameterCompletionProvider.cs (1)
108var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Completion\CompletionProviders\OperatorsAndIndexer\UnnamedSymbolCompletionProvider_Conversions.cs (1)
80var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Completion\CompletionProviders\OperatorsAndIndexer\UnnamedSymbolCompletionProvider_Operators.cs (1)
142var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Completion\CompletionProviders\SymbolCompletionProvider.cs (1)
177var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
ConvertPrimaryToRegularConstructor\ConvertPrimaryToRegularConstructorCodeRefactoringProvider.cs (2)
80var semanticModel = await GetSemanticModelAsync(document).ConfigureAwait(false); 239var semanticModel = await GetSemanticModelAsync(solution.GetRequiredDocument(syntaxTree)).ConfigureAwait(false);
Debugging\DataTipInfoGetter.cs (2)
39var semanticModel = await document.GetRequiredNullableDisabledSemanticModelAsync(cancellationToken).ConfigureAwait(false); 50var semanticModel = await document.GetRequiredNullableDisabledSemanticModelAsync(cancellationToken).ConfigureAwait(false);
Debugging\LocationInfoGetter.cs (1)
60var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
DocumentHighlighting\CSharpDocumentHighlightsService.cs (1)
63semanticModel ??= await document.GetRequiredNullableDisabledSemanticModelAsync(cancellationToken).ConfigureAwait(false);
Snippets\CSharpSnippetFunctionService.cs (1)
58var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\CSharp\CodeFixes\AddInheritdoc\AddInheritdocCodeFixProvider.cs (1)
71var sourceText = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\CSharp\CodeFixes\ConditionalExpressionInStringInterpolation\CSharpAddParenthesesAroundConditionalExpressionInInterpolatedStringCodeFixProvider.cs (2)
61var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 84var sourceText = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\CSharp\CodeFixes\NewLines\ArrowExpressionClausePlacement\ArrowExpressionClausePlacementCodeFixProvider.cs (1)
46var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\CSharp\CodeFixes\NewLines\ConditionalExpressionPlacement\ConditionalExpressionPlacementCodeFixProvider.cs (1)
46var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\CSharp\CodeFixes\NewLines\ConsecutiveBracePlacement\ConsecutiveBracePlacementCodeFixProvider.cs (1)
49var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\CSharp\CodeFixes\NewLines\ConstructorInitializerPlacement\ConstructorInitializerPlacementCodeFixProvider.cs (1)
46var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\CSharp\CodeFixes\UsePrimaryConstructor\CSharpUsePrimaryConstructorCodeFixProvider.cs (1)
129var removedMembers = await RemoveMembersAsync().ConfigureAwait(false);
StringIndentation\CSharpStringIndentationService.cs (1)
31var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.CSharp.Workspaces (2)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\CSharp\Services\SemanticFacts\CSharpSemanticFacts.cs (2)
457var contentHash = await document.GetContentHashAsync(cancellationToken).ConfigureAwait(false); 464foreach (var generatedDocument in await document.Project.GetSourceGeneratedDocumentsAsync(cancellationToken).ConfigureAwait(false))
Microsoft.CodeAnalysis.EditorFeatures (41)
AutomaticCompletion\BraceCompletionSessionProvider.BraceCompletionSession.cs (1)
124var hasBraceCompletions = await _service.HasBraceCompletionAsync(context, document, cancellationToken).ConfigureAwait(true);
Classification\Syntactic\SyntacticClassificationTaggerProvider.TagComputer.cs (1)
217cancellationToken).ConfigureAwait(false);
CodeActions\CodeActionEditHandlerService.cs (1)
135var text = await singleChangedDocument.GetValueTextAsync(cancellationToken).ConfigureAwait(true);
EditAndContinue\ActiveStatementTrackingService.cs (4)
173var compileTimeDocument = await compileTimeSolution.GetDocumentAsync(designTimeDocument.Id, includeSourceGenerated: true, cancellationToken).ConfigureAwait(false); 180_ = await GetAdjustedTrackingSpansAsync(compileTimeDocument, snapshot, cancellationToken).ConfigureAwait(false); 220documents.Add(await solution.GetTextDocumentAsync(id, cancellationToken).ConfigureAwait(false)); 319var document = await solution.GetTextDocumentAsync(documentId, cancellationToken).ConfigureAwait(false);
EditAndContinue\Contracts\ManagedHotReloadServiceBridge.cs (2)
17=> (await service.GetActiveStatementsAsync(cancellation).ConfigureAwait(false)).SelectAsArray(a => a.ToContract()); 20=> (await service.GetAvailabilityAsync(module, cancellation).ConfigureAwait(false)).ToContract();
EditAndContinue\EditAndContinueLanguageService.cs (3)
351? await EditSession.HasChangesAsync(oldSolution, newSolution, sourceFilePath, cancellationToken).ConfigureAwait(false) 352: await EditSession.HasChangesAsync(oldSolution, newSolution, cancellationToken).ConfigureAwait(false); 413await solution.GetDocumentAsync(diagnostic.DocumentId, includeSourceGenerated: true, cancellationToken).ConfigureAwait(false) == null)
EditorConfigSettings\Updater\SettingsUpdaterBase.cs (2)
55var originalText = await analyzerConfigDocument.GetValueTextAsync(token).ConfigureAwait(false); 84var originalText = await analyzerConfigDocument!.GetValueTextAsync(token).ConfigureAwait(false);
InlineRename\InlineRenameService.cs (1)
87var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
InlineRename\InlineRenameSession.OpenTextBufferManager.cs (2)
557var oldText = await oldDocument.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 558var newText = await newDocument.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Interactive\AbstractInteractiveWindowCommandCompletionProvider.cs (1)
28var sourceText = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Interactive\InteractiveDocumentNavigationService.cs (1)
50var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Navigation\AbstractDefinitionLocationService.cs (11)
49return await GetDefinitionLocationWorkerAsync(document.WithFrozenPartialSemantics(cancellationToken)).ConfigureAwait(false) ?? 50await GetDefinitionLocationWorkerAsync(document).ConfigureAwait(false); 55var semanticModel = await document.GetRequiredNullableDisabledSemanticModelAsync(cancellationToken).ConfigureAwait(false); 56return await GetControlFlowTargetLocationAsync(document, semanticModel).ConfigureAwait(false) ?? 57await GetSymbolLocationAsync(document, semanticModel).ConfigureAwait(false); 96solution, document, span, cancellationToken).ConfigureAwait(false); 146return await TryGetExplicitInterfaceLocationAsync().ConfigureAwait(false) ?? 147await TryGetInterceptedLocationAsync().ConfigureAwait(false) ?? 148await TryGetOtherPartOfPartialAsync().ConfigureAwait(false); 188var document = await project.GetDocumentAsync(contentHash, cancellationToken).ConfigureAwait(false); 286var semanticModel = await document.GetRequiredNullableDisabledSemanticModelAsync(cancellationToken).ConfigureAwait(false);
NavigationBar\NavigationBarController_ModelComputation.cs (2)
51return await ComputeModelAndSelectItemAsync(frozenPartialSemantics: false, linkedTokenSource.Token).ConfigureAwait(false); 61var model = await ComputeModelAndSelectItemAsync(frozenPartialSemantics: true, cancellationToken).ConfigureAwait(false);
Peek\PeekableItemFactory.cs (1)
62symbol = await GoToDefinitionFeatureHelpers.TryGetPreferredSymbolAsync(solution, symbol, cancellationToken).ConfigureAwait(false);
Peek\PeekableItemSource.cs (1)
135var text = await document.GetTextAsync(project.Solution, cancellationToken).ConfigureAwait(false);
QuickInfo\Extensions.cs (1)
50var sourceText = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
RenameTracking\RenameTrackingTaggerProvider.TrackingSession.cs (2)
201return await DetermineIfRenamableSymbolsAsync(renameSymbolInfo.Symbols, document).ConfigureAwait(false); 212return await DetermineIfRenamableSymbolAsync(renameSymbolInfo.Symbols.Single(), document, token).ConfigureAwait(false);
Tagging\AbstractAsynchronousTaggerProvider.TagSource_ProduceTags.cs (2)
253var (newTagTrees, newResult) = await callback(oldTagTrees, args, cancellationToken).ConfigureAwait(true); 299GetTaggerUIData, cancellationToken).ConfigureAwait(true);
TextDiffing\EditorTextDifferencingService.cs (2)
32var oldText = await oldDocument.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 33var newText = await newDocument.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.Extensions.Package (7)
src\Dependencies\Collections\Extensions\IEnumerableExtensions.cs (4)
483builder.Add(await selector(item).ConfigureAwait(false)); 498builder.Add(await selector(item, cancellationToken).ConfigureAwait(false)); 513builder.Add(await selector(item, arg, cancellationToken).ConfigureAwait(false)); 525builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
src\Dependencies\Collections\Extensions\ImmutableArrayExtensions.cs (3)
427builder[i] = await selector(array[i], cancellationToken).ConfigureAwait(false); 445builder[i] = await selector(array[i], arg, cancellationToken).ConfigureAwait(false); 471builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
Microsoft.CodeAnalysis.ExternalAccess.AspNetCore (1)
AddPackage\AspNetCoreAddPackageCodeAction.cs (1)
68updatedDocument, codeCleanupOptions, cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.ExternalAccess.Copilot (1)
Internal\SemanticSearch\SemanticSearchCopilotServiceWrapper.cs (1)
35cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.ExternalAccess.FSharp (1)
TaskList\FSharpTaskListService.cs (1)
41var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.ExternalAccess.OmniSharp (1)
Completion\OmniSharpCompletionService.cs (1)
24var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.ExternalAccess.Razor.Features (9)
RazorProjectExtensions.cs (1)
22var results = await project.GetSourceGeneratedDocumentsAsync(cancellationToken).ConfigureAwait(false);
Remote\RazorRemoteHostClient.cs (8)
43return await connection.TryInvokeAsync(invocation, cancellationToken).ConfigureAwait(false); 49return await connection.TryInvokeAsync(invocation, cancellationToken).ConfigureAwait(false); 57return await connection.TryInvokeAsync(invocation, cancellationToken).ConfigureAwait(false); 63return await connection.TryInvokeAsync(invocation, cancellationToken).ConfigureAwait(false); 71return await connection.TryInvokeAsync(solution, invocation, cancellationToken).ConfigureAwait(false); 77return await connection.TryInvokeAsync(solution, invocation, cancellationToken).ConfigureAwait(false); 85return await connection.TryInvokeAsync(solution, invocation, cancellationToken).ConfigureAwait(false); 91return await connection.TryInvokeAsync(solution, invocation, cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.ExternalAccess.Xaml (1)
Internal\LocationService.cs (1)
40var sourceText = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.Features (215)
AddFileBanner\AbstractAddFileBannerCodeRefactoringProvider.cs (1)
136var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
AddImport\AbstractAddImportCodeFixProvider.cs (2)
59var searchOptions = await document.GetSymbolSearchOptionsAsync(cancellationToken).ConfigureAwait(false); 75var addImportOptions = await document.GetAddImportOptionsAsync(searchOptions, cancellationToken).ConfigureAwait(false);
AddImport\CodeActions\AddImportCodeAction.cs (1)
61var oldText = await OriginalDocument.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
AddImport\CodeActions\InstallPackageAndAddImportCodeAction.cs (2)
86var oldText = await OriginalDocument.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 87var newText = await updatedDocument.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
AddImport\References\Reference.cs (1)
120newDocument, options, cancellationToken).ConfigureAwait(false);
AddImport\References\SymbolReference.cs (1)
67updatedDocument, options, cancellationToken).ConfigureAwait(false);
AddPackage\AbstractAddPackageCodeFixProvider.cs (1)
44var options = await document.GetSymbolSearchOptionsAsync(cancellationToken).ConfigureAwait(false);
BraceMatching\AbstractBraceMatcher.cs (1)
67var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
BraceMatching\BraceMatchingService.cs (1)
26var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
ClassifiedSpansAndHighlightSpanFactory.cs (1)
34var sourceText = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
CodeFixes\Configuration\ConfigurationUpdater.cs (1)
271var originalText = await editorConfigDocument.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
CodeFixes\Service\CodeFixService.cs (4)
122var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 216var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 235var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 348var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
CodeFixes\Suppression\AbstractSuppressionBatchFixAllProvider.cs (1)
314var finalText = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
CodeFixes\Suppression\AbstractSuppressionCodeFixProvider.GlobalSuppressMessageFixAllCodeAction.cs (1)
148var final = await CleanupDocumentAsync(result, cleanupOptions, cancellationToken).ConfigureAwait(false);
CodeFixes\Suppression\AbstractSuppressionCodeFixProvider.PragmaBatchFixHelpers.cs (1)
105var currentText = await currentDocument.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
CodeLens\CodeLensReferencesService.cs (3)
46var document = await solution.GetDocumentAsync(documentId, includeSourceGenerated: true, cancellationToken).ConfigureAwait(false); 91var projectVersion = await GetProjectCodeLensVersionAsync(solution, documentId.ProjectId, cancellationToken).ConfigureAwait(false); 124var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
CodeRefactorings\AddMissingImports\AbstractAddMissingImportsFeatureService.cs (3)
56cancellationToken).ConfigureAwait(false); 116var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 153var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
CodeRefactorings\SyncNamespace\AbstractSyncNamespaceCodeRefactoringProvider.MoveFileCodeAction.cs (1)
45var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Completion\CompletionProvider.cs (1)
58=> ShouldTriggerCompletion(document.Project.Services, await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false), caretPosition, trigger, options, document.Project.Solution.Options);
Completion\CompletionService.cs (1)
417var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Completion\CompletionService_GetCompletions.cs (1)
75var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Completion\Providers\AbstractAwaitCompletionProvider.cs (1)
230var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Completion\Providers\AbstractDocCommentCompletionProvider.cs (1)
278var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Completion\Providers\AbstractInternalsVisibleToCompletionProvider.cs (1)
256var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Completion\Providers\AbstractMemberInsertingCompletionProvider.cs (4)
51var newText = await newDocument.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 65var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 185var text = await memberContainingDocument.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 228text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Completion\Providers\AbstractOverrideCompletionProvider.ItemGetter.cs (1)
39var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Completion\Providers\AbstractPartialMethodCompletionProvider.cs (1)
99var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Completion\Providers\AbstractRecommendationServiceBasedCompletionProvider.cs (1)
271var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Completion\Providers\ImportCompletionProvider\AbstractImportCompletionProvider.cs (1)
163var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Completion\Providers\Snippets\AbstractSnippetCompletionProvider.cs (2)
36var strippedText = await strippedDocument.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 122var originalText = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
ConvertTupleToStruct\AbstractConvertTupleToStructCodeRefactoringProvider.cs (1)
187var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Copilot\ICopilotChangeAnalysisService.cs (1)
128var sourceGeneratedDocuments = await newDocument.Project.GetSourceGeneratedDocumentsAsync(cancellationToken).ConfigureAwait(false);
Debugging\AbstractDataTipInfoGetter.cs (1)
29var semanticModel = await document.GetRequiredNullableDisabledSemanticModelAsync(cancellationToken).ConfigureAwait(false);
DesignerAttribute\DesignerAttributeDiscoveryService.cs (1)
258hasDesignerCategoryType ??= await HasDesignerCategoryTypeAsync(project, cancellationToken).ConfigureAwait(false);
Diagnostics\Service\DocumentAnalysisExecutor.cs (1)
133var sourceText = await textDocument.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Diagnostics\Service\DocumentAnalysisExecutor_Helpers.cs (1)
180var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Diagnostics\Service\EngineV2\DiagnosticIncrementalAnalyzer_GetDiagnosticsForSpan.cs (1)
59var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Diagnostics\Service\EngineV2\InProcOrRemoteHostAnalyzerRunner.cs (1)
195cancellationToken).ConfigureAwait(false);
DocumentHighlighting\AbstractDocumentHighlightsService.cs (1)
68var semanticModel = await document.GetRequiredNullableDisabledSemanticModelAsync(cancellationToken).ConfigureAwait(false);
DocumentIdSpan.cs (1)
30var document = await solution.GetDocumentAsync(this.DocumentId, includeSourceGenerated: true, cancellationToken).ConfigureAwait(false);
EditAndContinue\AbstractEditAndContinueAnalyzer.cs (7)
522var (oldDocument, oldText) = await GetDocumentContentAsync(oldProject, documentId, cancellationToken).ConfigureAwait(false); 523var (newDocument, newText) = await GetDocumentContentAsync(newProject, documentId, cancellationToken).ConfigureAwait(false); 549var (oldRoot, newRoot) = await GetSyntaxRootsAsync(oldDocument, newDocument, cancellationToken).ConfigureAwait(false); 629var oldModel = await GetDocumentSemanticModelAsync(oldProject, oldDocument, oldTree, cancellationToken).ConfigureAwait(false); 630var newModel = await GetDocumentSemanticModelAsync(newProject, newDocument, newTree, cancellationToken).ConfigureAwait(false); 728var document = await project.GetDocumentAsync(documentId, includeSourceGenerated: true, cancellationToken).ConfigureAwait(false); 772return new DocumentSemanticModel(await document.GetRequiredNullableDisabledSemanticModelAsync(cancellationToken).ConfigureAwait(false));
EditAndContinue\CommittedSolution.cs (6)
207var sourceGeneratedDocument = await solution.GetSourceGeneratedDocumentAsync(documentId, cancellationToken).ConfigureAwait(false); 248var sourceText = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 347? await TryGetMatchingSourceTextAsync(_debuggingSession.SessionLog, sourceText, document.FilePath, currentDocument, _debuggingSession.SourceTextProvider, requiredChecksum, checksumAlgorithm, cancellationToken).ConfigureAwait(false) 363var currentDocumentSourceText = await currentDocument.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 370var text = await sourceTextProvider.TryGetMatchingSourceTextAsync(filePath, requiredChecksum, checksumAlgorithm, cancellationToken).ConfigureAwait(false); 418var sourceText = await documentState.GetTextAsync(cancellationToken).ConfigureAwait(false);
EditAndContinue\DebuggingSession.cs (5)
482var analysis = await EditSession.Analyses.GetDocumentAnalysisAsync(LastCommittedSolution, document.Project.Solution, oldDocument, document, activeStatementSpanProvider, cancellationToken).ConfigureAwait(false); 524var solutionUpdate = await EditSession.EmitSolutionUpdateAsync(solution, activeStatementSpanProvider, updateId, runningProjects, cancellationToken).ConfigureAwait(false); 740var document = await solution.GetTextDocumentAsync(documentId, cancellationToken).ConfigureAwait(false); 902var newDocumentActiveStatementSpans = await activeStatementSpanProvider(mappedDocument.Id, mappedDocument.FilePath, cancellationToken).ConfigureAwait(false); 927var analysis = await EditSession.Analyses.GetDocumentAnalysisAsync(LastCommittedSolution, newUnmappedDocument.Project.Solution, oldUnmappedDocument, newUnmappedDocument, activeStatementSpanProvider, cancellationToken).ConfigureAwait(false);
EditAndContinue\EditAndContinueDocumentAnalysesCache.cs (2)
131var newMappedDocumentSpans = await newActiveStatementSpanProvider(newDocument.Id, newDocument.FilePath, cancellationToken).ConfigureAwait(false); 151newMappedDocumentSpans = await newActiveStatementSpanProvider((newDocument.FilePath == mappedFilePath) ? newDocument.Id : null, mappedFilePath, cancellationToken).ConfigureAwait(false);
EditAndContinue\EditSession.cs (26)
159var availability = await DebuggingSession.DebuggerService.GetAvailabilityAsync(mvid, cancellationToken).ConfigureAwait(false); 186var oldDocument = await oldProject.GetDocumentAsync(documentAnalysis.DocumentId, includeSourceGenerated: true, cancellationToken).ConfigureAwait(false); 187var newDocument = await newProject.GetDocumentAsync(documentAnalysis.DocumentId, includeSourceGenerated: true, cancellationToken).ConfigureAwait(false); 233var capabilities = await DebuggingSession.DebuggerService.GetCapabilitiesAsync(cancellationToken).ConfigureAwait(false); 247var debugInfos = await DebuggingSession.DebuggerService.GetActiveStatementsAsync(cancellationToken).ConfigureAwait(false); 276return oldDocument != newDocument && !await ContentEqualsAsync(oldDocument, newDocument, cancellationToken).ConfigureAwait(false); 294if (oldProject == null || await HasDocumentDifferencesAsync(oldProject, newProject, documentDifferences: null, cancellationToken).ConfigureAwait(false)) 330var oldSource = await oldDocument.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 331var newSource = await newDocument.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 355if (await ContentEqualsAsync(oldProject.GetRequiredDocument(documentId), document, cancellationToken).ConfigureAwait(false)) 411if (!await ContentEqualsAsync(oldProject.GetRequiredAdditionalDocument(documentId), document, cancellationToken).ConfigureAwait(false)) 420if (!await ContentEqualsAsync(oldProject.GetRequiredAnalyzerConfigDocument(documentId), document, cancellationToken).ConfigureAwait(false)) 441if (!await HasDocumentDifferencesAsync(oldProject, newProject, documentDifferences, cancellationToken).ConfigureAwait(false)) 446var oldSourceGeneratedDocumentStates = await GetSourceGeneratedDocumentStatesAsync(log, oldProject, diagnostics, cancellationToken).ConfigureAwait(false); 449var newSourceGeneratedDocumentStates = await GetSourceGeneratedDocumentStatesAsync(log, newProject, diagnostics, cancellationToken).ConfigureAwait(false); 536var oldSourceGeneratedDocumentStates = await GetSourceGeneratedDocumentStatesAsync(log, oldProject, diagnostics: null, cancellationToken).ConfigureAwait(false); 539var newSourceGeneratedDocumentStates = await GetSourceGeneratedDocumentStatesAsync(log, newProject, diagnostics: null, cancellationToken).ConfigureAwait(false); 598: await Analyses.GetDocumentAnalysesAsync(DebuggingSession.LastCommittedSolution, newSolution, documents, newDocumentActiveStatementSpanProvider, cancellationToken).ConfigureAwait(false); 683var oldDocument = await oldProject.GetDocumentAsync(analysis.DocumentId, includeSourceGenerated: true, cancellationToken).ConfigureAwait(false); 686await baseActiveStatements.GetOldActiveStatementsAsync(analyzer, oldDocument, cancellationToken).ConfigureAwait(false); 1019var document = await solution.GetDocumentAsync(analysis.DocumentId, includeSourceGenerated: true, cancellationToken).ConfigureAwait(false); 1061var projectChanges = await GetProjectChangesAsync(oldActiveStatementsMap, oldCompilation, newCompilation, oldProject, newProject, changedDocumentAnalyses, cancellationToken).ConfigureAwait(false); 1191var oldDocument = await oldProject.GetDocumentAsync(changedDocumentAnalysis.DocumentId, includeSourceGenerated: true, cancellationToken).ConfigureAwait(false); 1192var newDocument = await newProject.GetDocumentAsync(changedDocumentAnalysis.DocumentId, includeSourceGenerated: true, cancellationToken).ConfigureAwait(false); 1281async (stream, cancellationToken) => await oldCompilationOutputs.TryCopyAssemblyToAsync(stream, cancellationToken).ConfigureAwait(false), 1288async (stream, cancellationToken) => await oldCompilationOutputs.TryCopyPdbToAsync(stream, cancellationToken).ConfigureAwait(false),
EditAndContinue\Remote\ActiveStatementSpanProviderCallback.cs (1)
24return await _provider(documentId, filePath, cancellationToken).ConfigureAwait(false);
EditAndContinue\Remote\RemoteDebuggingSessionProxy.cs (3)
66return (await GetLocalService().EmitSolutionUpdateAsync(sessionId, solution, runningProjects, activeStatementSpanProvider, cancellationToken).ConfigureAwait(false)).Dehydrate(); 135return await GetLocalService().GetBaseActiveStatementSpansAsync(sessionId, solution, documentIds, cancellationToken).ConfigureAwait(false); 157return await GetLocalService().GetAdjustedActiveStatementSpansAsync(sessionId, document, activeStatementSpanProvider, cancellationToken).ConfigureAwait(false);
EditAndContinue\Remote\RemoteEditAndContinueServiceProxy.cs (6)
60return await _sourceTextProvider.TryGetMatchingSourceTextAsync(filePath, requiredChecksum, checksumAlgorithm, cancellationToken).ConfigureAwait(false); 72return await _debuggerService.GetActiveStatementsAsync(cancellationToken).ConfigureAwait(false); 84return await _debuggerService.GetAvailabilityAsync(mvid, cancellationToken).ConfigureAwait(false); 108return await _debuggerService.GetCapabilitiesAsync(cancellationToken).ConfigureAwait(false); 132var sessionId = await GetLocalService().StartDebuggingSessionAsync(solution, debuggerService, sourceTextProvider, captureMatchingDocuments, captureAllMatchingDocuments, reportDiagnostics, cancellationToken).ConfigureAwait(false); 165var diagnostics = await GetLocalService().GetDocumentDiagnosticsAsync(document, activeStatementSpanProvider, cancellationToken).ConfigureAwait(false);
EditAndContinue\TraceLog.cs (1)
115var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
EmbeddedLanguages\Classification\AbstractEmbeddedLanguageClassificationService.cs (1)
44semanticModel = await document.GetRequiredNullableDisabledSemanticModelAsync(cancellationToken).ConfigureAwait(false);
EmbeddedLanguages\DateAndTime\DateAndTimeEmbeddedCompletionProvider.cs (1)
95var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Extensions\ExtensionMessageHandlerService.cs (1)
181return await extensionFolder.GetExtensionMessageNamesAsync(assemblyFilePath, cancellationToken).ConfigureAwait(false);
Extensions\ExtensionMessageHandlerService_RemoteOrLocal.cs (2)
41cancellationToken).ConfigureAwait(false); 53return await executeInProcessAsync(this, arg, cancellationToken).ConfigureAwait(false);
ExternalAccess\UnitTesting\API\UnitTestingHotReloadService.cs (2)
75cancellationToken).ConfigureAwait(false); 99.ConfigureAwait(false);
ExternalAccess\UnitTesting\SolutionCrawler\UnitTestingWorkCoordinator.cs (1)
382foreach (var document in await project.GetSourceGeneratedDocumentsAsync(_shutdownToken).ConfigureAwait(false))
ExternalAccess\UnitTesting\SolutionCrawler\UnitTestingWorkCoordinator.UnitTestingNormalPriorityProcessor.cs (1)
205var textDocument = solution.GetTextDocument(documentId) ?? await solution.GetSourceGeneratedDocumentAsync(documentId, cancellationToken).ConfigureAwait(false);
ExternalAccess\VSTypeScript\VSTypeScriptTaskListService.cs (1)
36var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
ExternalAccess\Watch\Api\WatchHotReloadService.cs (2)
170cancellationToken).ConfigureAwait(false); 215var results = await _encService.EmitSolutionUpdateAsync(sessionId, solution, runningProjectsImpl, s_solutionActiveStatementSpanProvider, cancellationToken).ConfigureAwait(false);
FindUsages\AbstractFindUsagesService.ProgressAdapter.cs (3)
36var options = await classificationOptions.GetOptionsAsync(document.Project.Services, cancellationToken).ConfigureAwait(false); 99cancellationToken).ConfigureAwait(false); 110var definitionItem = await GetDefinitionItemAsync(group, cancellationToken).ConfigureAwait(false);
FindUsages\AbstractFindUsagesService_FindImplementations.cs (1)
88classificationOptions, solution, FindReferencesSearchOptions.Default, isPrimary: true, includeHiddenLocations: false, cancellationToken).ConfigureAwait(false);
FindUsages\DefinitionItem.DefaultDefinitionItem.cs (1)
44var (project, symbol) = await TryResolveSymbolAsync(workspace.CurrentSolution, symbolKey, cancellationToken).ConfigureAwait(false);
FindUsages\DefinitionItemFactory.cs (3)
71var classifiedSpans = await ClassifyDocumentSpansAsync(classificationOptions, sourceLocations, cancellationToken).ConfigureAwait(false); 89var classifiedSpans = await ClassifyDocumentSpansAsync(classificationOptions, sourceLocations, cancellationToken).ConfigureAwait(false); 303var options = await optionsProvider.GetOptionsAsync(document.Project.Services, cancellationToken).ConfigureAwait(false);
FindUsages\IRemoteFindUsagesService.cs (3)
117var rehydrated = await definition.RehydrateAsync(_solution, cancellationToken).ConfigureAwait(false); 176await solution.GetSourceGeneratedDocumentAsync(DocumentId, cancellationToken).ConfigureAwait(false); 307await SourceSpan.RehydrateAsync(solution, cancellationToken).ConfigureAwait(false),
Formatting\AbstractNewDocumentFormattingService.cs (1)
55document = await CodeAction.CleanupDocumentAsync(document, options, cancellationToken).ConfigureAwait(false);
FullyQualify\AbstractFullyQualifyCodeFixProvider.cs (1)
40var sourceText = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
FullyQualify\AbstractFullyQualifyService.cs (1)
223newDocument, await document.GetCodeCleanupOptionsAsync(cancellationToken).ConfigureAwait(false), cancellationToken).ConfigureAwait(false);
GenerateConstructors\AbstractGenerateConstructorsCodeRefactoringProvider.ConstructorDelegatingCodeAction.cs (1)
54var useThrowExpressions = await _service.PrefersThrowExpressionAsync(_document, cancellationToken).ConfigureAwait(false);
GenerateConstructors\AbstractGenerateConstructorsCodeRefactoringProvider.cs (1)
122var sourceText = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
GenerateConstructors\AbstractGenerateConstructorsCodeRefactoringProvider.FieldDelegatingCodeAction.cs (1)
48var preferThrowExpression = await _service.PrefersThrowExpressionAsync(_document, cancellationToken).ConfigureAwait(false);
GenerateType\AbstractGenerateTypeService.cs (1)
74var state = await State.GenerateAsync((TService)this, semanticDocument, node, cancellationToken).ConfigureAwait(false);
GenerateType\AbstractGenerateTypeService.State.cs (1)
75return await state.TryInitializeAsync(service, document, node, cancellationToken).ConfigureAwait(false) ? state : (State?)null;
GoToBase\AbstractGoToBaseService.cs (1)
69classificationOptions, solution, FindReferencesSearchOptions.Default, isPrimary: true, includeHiddenLocations: false, cancellationToken: cancellationToken).ConfigureAwait(false);
GoToDefinition\GoToDefinitionFeatureHelpers.cs (1)
58symbol = await TryGetPreferredSymbolAsync(solution, symbol, cancellationToken).ConfigureAwait(false);
InheritanceMargin\AbstractInheritanceMarginService_Helpers.cs (8)
85var sourceText = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 132var (remappedProject, symbolAndLineNumbers) = await GetMemberSymbolsAsync(document, spanToSearch, cancellationToken).ConfigureAwait(false); 151cancellationToken).ConfigureAwait(false)); 212var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 323cancellationToken).ConfigureAwait(false); 335cancellationToken).ConfigureAwait(false); 365cancellationToken).ConfigureAwait(false); 393cancellationToken).ConfigureAwait(false);
IntroduceUsingStatement\AbstractIntroduceUsingStatementCodeRefactoringProvider.cs (2)
210var options = await document.GetAnalyzerOptionsProviderAsync(cancellationToken).ConfigureAwait(false); 217var semanticModel = await document.GetRequiredNullableDisabledSemanticModelAsync(cancellationToken).ConfigureAwait(false);
InvertIf\AbstractInvertIfCodeRefactoringProvider.cs (1)
295var sourceText = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
NavigateTo\AbstractNavigateToSearchService.GeneratedDocumentSearch.cs (1)
79var sourceGeneratedDocs = await project.GetSourceGeneratedDocumentsAsync(cancellationToken).ConfigureAwait(false);
NavigateTo\AbstractNavigateToSearchService.NormalSearch.cs (1)
109var semanticModel = await document.GetRequiredNullableDisabledSemanticModelAsync(cancellationToken).ConfigureAwait(false);
NavigateTo\INavigateToSearcherHost.cs (1)
59return await workspaceService.IsFullyLoadedAsync(cancellationToken).ConfigureAwait(false);
NavigateTo\NavigateToSearcher.cs (1)
160isFullyLoaded = await _host.IsFullyLoadedAsync(cancellationToken).ConfigureAwait(false);
Navigation\AbstractNavigableItemsService.cs (3)
46var semanticModel = await document.GetRequiredNullableDisabledSemanticModelAsync(cancellationToken).ConfigureAwait(false); 52symbol = await GoToDefinitionFeatureHelpers.TryGetPreferredSymbolAsync(solution, symbol, cancellationToken).ConfigureAwait(false); 65typeSymbol = await GoToDefinitionFeatureHelpers.TryGetPreferredSymbolAsync(solution, typeSymbol, cancellationToken).ConfigureAwait(false);
Navigation\INavigableItem.cs (2)
79var document = await GetRequiredDocumentAsync(solution, cancellationToken).ConfigureAwait(false); 80return await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
QuickInfo\Presentation\QuickInfoContentBuilder.cs (1)
136var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
RelatedDocuments\AbstractRelatedDocumentsService.cs (1)
74var semanticModel = await document.GetRequiredNullableDisabledSemanticModelAsync(cancellationToken).ConfigureAwait(false);
Rename\SymbolicRenameInfo.cs (1)
256var sourceText = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
ReplaceDocCommentTextWithTag\AbstractReplaceDocCommentTextWithTagCodeRefactoringProvider.cs (1)
160var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
SemanticSearch\IRemoteSemanticSearchService.cs (2)
63var rehydratedDefinition = await definition.RehydrateAsync(solution, cancellationToken).ConfigureAwait(false); 108return await classificationOptions.GetOptionsAsync(solution.Services.GetLanguageServices(language), cancellationToken).ConfigureAwait(false);
SemanticSearch\QueryExecutionContext.cs (1)
158classificationOptions, project.Solution, s_findReferencesSearchOptions, isPrimary: true, includeHiddenLocations: false, cancellationToken).ConfigureAwait(false);
Snippets\RoslynLSPSnippetConverter.cs (1)
111var documentText = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Snippets\SnippetFunctionService.cs (1)
44var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Snippets\SnippetProviders\AbstractSnippetProvider.cs (1)
190var originalText = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\ConflictMarkerResolution\AbstractConflictMarkerCodeFixProvider.cs (3)
75var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 319var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 405var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\Formatting\FormattingCodeFixProvider.cs (1)
73var text = await context.Document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\GenerateConstructor\AbstractGenerateConstructorService.State.cs (7)
87if (!(await TryInitializeConstructorInitializerGenerationAsync(node, cancellationToken).ConfigureAwait(false))) 92if (!(await TryInitializeSimpleNameGenerationAsync(node, cancellationToken).ConfigureAwait(false))) 97if (!(await TryInitializeImplicitObjectCreationAsync(node, cancellationToken).ConfigureAwait(false))) 306return await TryDetermineTypeToGenerateInAsync(typeToGenerateIn, cancellationToken).ConfigureAwait(false); 323return await TryDetermineTypeToGenerateInAsync(typeToGenerateIn, cancellationToken).ConfigureAwait(false); 356return await TryDetermineTypeToGenerateInAsync(typeToGenerateIn, cancellationToken).ConfigureAwait(false); 397var definition = await SymbolFinderInternal.FindSourceDefinitionAsync(original, _document.Project.Solution, cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\GenerateEnumMember\AbstractGenerateEnumMemberService.State.cs (2)
34return await state.TryInitializeAsync(service, document, node, cancellationToken).ConfigureAwait(false) ? state : null; 67var sourceType = (await SymbolFinderInternal.FindSourceDefinitionAsync(TypeToGenerateIn, document.Project.Solution, cancellationToken).ConfigureAwait(false)) as INamedTypeSymbol;
src\Analyzers\Core\CodeFixes\GenerateParameterizedMember\AbstractGenerateConversionService.cs (1)
41return await GetActionsAsync(document, state, cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\GenerateParameterizedMember\AbstractGenerateDeconstructMethodService.cs (1)
36return state != null ? await GetActionsAsync(document, state, cancellationToken).ConfigureAwait(false) : [];
src\Analyzers\Core\CodeFixes\GenerateParameterizedMember\AbstractGenerateMethodService.cs (1)
42return await GetActionsAsync(document, state, cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\GenerateParameterizedMember\AbstractGenerateParameterizedMemberService.CodeAction.cs (2)
68var property = await _state.SignatureInfo.GeneratePropertyAsync(syntaxFactory, _isAbstract, _state.IsWrittenTo, cancellationToken).ConfigureAwait(false); 84var method = await _state.SignatureInfo.GenerateMethodAsync(syntaxFactory, _isAbstract, cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\GenerateParameterizedMember\AbstractGenerateParameterizedMemberService.cs (1)
59var returnType = await state.SignatureInfo.DetermineReturnTypeAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\GenerateParameterizedMember\AbstractGenerateParameterizedMemberService.SignatureInfo.cs (5)
80type: await DetermineReturnTypeAsync(cancellationToken).ConfigureAwait(false), 84parameters: await DetermineParametersAsync(cancellationToken).ConfigureAwait(false), 94var parameters = await DetermineParametersAsync(cancellationToken).ConfigureAwait(false); 95var returnType = await DetermineReturnTypeAsync(cancellationToken).ConfigureAwait(false); 154Document.Project, typeSymbol, compilation, availableTypeParameterNames, cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\GenerateParameterizedMember\AbstractGenerateParameterizedMemberService.State.cs (2)
61TypeToGenerateIn = await SymbolFinderInternal.FindSourceDefinitionAsync(TypeToGenerateIn, document.Project.Solution, cancellationToken).ConfigureAwait(false) as INamedTypeSymbol; 90var generatedMethod = await SignatureInfo.GenerateMethodAsync(syntaxFactory, false, cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\GenerateParameterizedMember\TypeParameterSubstitution.cs (2)
78var commonDerivedType = await DetermineCommonDerivedTypeAsync(symbol).ConfigureAwait(false); 113_project, commonType, _compilation, _availableTypeParameterNames, _cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\GenerateVariable\AbstractGenerateVariableService.cs (1)
41var state = await State.GenerateAsync((TService)this, semanticDocument, node, cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\GenerateVariable\AbstractGenerateVariableService.State.cs (1)
80return await state.TryInitializeAsync(interfaceNode, cancellationToken).ConfigureAwait(false) ? state : null;
src\Analyzers\Core\CodeFixes\ImplementAbstractClass\ImplementAbstractClassData.cs (1)
65var options = await document.GetImplementTypeOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\ImplementInterface\AbstractImplementInterfaceCodeFixProvider.cs (1)
42var options = await document.GetImplementTypeOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\OrderModifiers\AbstractOrderModifiersCodeFixProvider.cs (1)
52var options = await document.GetAnalyzerOptionsProviderAsync(cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\UnsealClass\AbstractUnsealClassCodeFixProvider.cs (1)
43type, document.Project.Solution, cancellationToken).ConfigureAwait(false);
src\Analyzers\Core\CodeFixes\UseConditionalExpression\AbstractUseConditionalExpressionCodeFixProvider.cs (1)
148var sourceText = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
ValueTracking\SerializableValueTrackedItem.cs (1)
51var parent = Parent is null ? null : await Parent.RehydrateAsync(solution, cancellationToken).ConfigureAwait(false);
ValueTracking\ValueTrackingProgressCollector.cs (1)
42var item = await ValueTrackedItem.TryCreateAsync(solution, location, symbol, Parent, cancellationToken).ConfigureAwait(false);
Workspace\CompileTimeSolutionProvider.cs (1)
179var compileTimeDocument = await compileTimeSolution.GetDocumentAsync(designTimeDocument.Id, includeSourceGenerated: true, cancellationToken).ConfigureAwait(false);
Wrapping\AbstractWrapper.cs (1)
46var sourceText = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Wrapping\BinaryExpression\AbstractBinaryExpressionWrapper.cs (1)
90var sourceText = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Wrapping\ChainedExpression\AbstractChainedExpressionWrapper.cs (1)
111var sourceText = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Wrapping\SeparatedSyntaxList\AbstractSeparatedSyntaxListWrapper.cs (1)
84var sourceText = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.Features.UnitTests (1)
EditAndContinue\EditAndContinueWorkspaceServiceTests.cs (1)
4303var generatedDocument1 = (await solution.Projects.Single().GetSourceGeneratedDocumentsAsync().ConfigureAwait(false)).Single();
Microsoft.CodeAnalysis.InteractiveHost (11)
Interactive\Core\InteractiveHost.RemoteService.cs (1)
85using (await _disposeSemaphore.DisposableWaitAsync().ConfigureAwait(false))
src\Dependencies\Collections\Extensions\IEnumerableExtensions.cs (4)
483builder.Add(await selector(item).ConfigureAwait(false)); 498builder.Add(await selector(item, cancellationToken).ConfigureAwait(false)); 513builder.Add(await selector(item, arg, cancellationToken).ConfigureAwait(false)); 525builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
src\Dependencies\Collections\Extensions\ImmutableArrayExtensions.cs (3)
427builder[i] = await selector(array[i], cancellationToken).ConfigureAwait(false); 445builder[i] = await selector(array[i], arg, cancellationToken).ConfigureAwait(false); 471builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
src\Dependencies\Threading\AsyncBatchingWorkQueue`2.cs (1)
220return (ranToCompletion: true, await ProcessNextBatchAsync().ConfigureAwait(false));
src\Dependencies\Threading\ValueTaskExtensions.cs (2)
237_task.ConfigureAwait(_captureContext).GetAwaiter().OnCompleted(continuation); 247_task.ConfigureAwait(_captureContext).GetAwaiter().UnsafeOnCompleted(continuation);
Microsoft.CodeAnalysis.LanguageServer.Protocol (49)
Extensions\Extensions.cs (3)
108var textDocument = await solution.GetTextDocumentAsync(documentIdentifier, cancellationToken).ConfigureAwait(false); 124return await solution.GetDocumentAsync(documentId, includeSourceGenerated: true, cancellationToken).ConfigureAwait(false); 205var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Extensions\ProtocolConversions.cs (4)
177var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 401var oldText = await oldDocument.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 414var newText = await newDocument.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 512var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Features\EditAndContinue\EditAndContinueDiagnosticSource_Workspace.cs (1)
59var document = await solution.GetDocumentAsync(documentId, includeSourceGenerated: true, cancellationToken).ConfigureAwait(false);
Features\UnifiedSuggestions\UnifiedSuggestedActionsSource.cs (1)
55var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Handler\Breakpoints\ValidateBreakableRangeHandler.cs (1)
36var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Handler\CodeActions\CodeActionHelpers.cs (5)
43document, codeFixService, codeRefactoringService, request.Range, cancellationToken).ConfigureAwait(false); 51var documentText = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 320document, codeFixService, codeRefactoringService, selection, cancellationToken).ConfigureAwait(false); 395var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 401cancellationToken).ConfigureAwait(false);
Handler\CodeActions\CodeActionResolveHelper.cs (3)
259var newText = await newTextDoc.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 284var oldText = await oldTextDoc.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 297var newText = await newTextDoc.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Handler\CodeLens\CodeLensHandler.cs (1)
65var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Handler\Completion\CompletionHandler.cs (1)
81var documentText = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Handler\Completion\CompletionResultFactory.cs (1)
62var documentText = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Handler\DataTips\DataTipRangeHandler.cs (1)
35var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Handler\Diagnostics\AbstractPullDiagnosticHandler.cs (2)
143diagnosticsParams, category, context, cancellationToken).ConfigureAwait(false); 248var document = await solution.GetTextDocumentAsync(textDocumentIdentifier, cancellationToken).ConfigureAwait(false);
Handler\Diagnostics\DiagnosticSourceProviders\DiagnosticSourceManager.cs (2)
74return await provider.CreateDiagnosticSourcesAsync(context, cancellationToken).ConfigureAwait(false); 90var namedSources = await provider.CreateDiagnosticSourcesAsync(context, cancellationToken).ConfigureAwait(false);
Handler\Diagnostics\DiagnosticSourceProviders\WorkspaceDocumentsAndProjectDiagnosticSourceProvider.cs (1)
76var sourceGeneratedDocuments = await project.GetSourceGeneratedDocumentsAsync(cancellationToken).ConfigureAwait(false);
Handler\Diagnostics\DiagnosticSources\AbstractWorkspaceDocumentDiagnosticSource.cs (1)
56var projectDiagnostics = await GetProjectDiagnosticsAsync(cancellationToken).ConfigureAwait(false);
Handler\FoldingRanges\FoldingRangesHandler.cs (1)
78var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Handler\Formatting\AbstractFormatDocumentHandlerBase.cs (1)
34var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Handler\Highlights\DocumentHighlightHandler.cs (1)
55var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Handler\Hover\HoverHandler.cs (2)
109var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 140var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Handler\InlayHint\InlayHintHandler.cs (2)
52var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 99var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Handler\InlineCompletions\InlineCompletionsHandler.cs (1)
129var sourceText = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Handler\MapCode\MapCodeHandler.cs (1)
85var document = await context.Solution.GetDocumentAsync(textDocument, cancellationToken).ConfigureAwait(false);
Handler\OnAutoInsert\OnAutoInsertHandler.cs (2)
151var sourceText = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 226var documentText = await oldDocument.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Handler\References\FindUsagesLSPContext.cs (1)
313var docText = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Handler\SemanticTokens\SemanticTokensHelpers.cs (1)
92var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Handler\SourceGenerators\SourceGeneratedDocumentCache.cs (1)
45var unfrozenDocument = await state.Document.Project.Solution.WithoutFrozenSourceGeneratedDocuments().GetDocumentAsync(state.Document.Id, includeSourceGenerated: true, cancellationToken).ConfigureAwait(false);
Handler\SpellCheck\AbstractSpellCheckingHandler.cs (2)
145var document = await context.Solution.GetDocumentAsync(requestParams.TextDocument, cancellationToken).ConfigureAwait(false); 212var document = await context.Solution.GetTextDocumentAsync(textDocument, cancellationToken).ConfigureAwait(false);
Handler\Symbols\DocumentSymbolsHandler.cs (1)
59var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Workspaces\LspWorkspaceManager.cs (4)
254var document = await lspSolution.GetTextDocumentAsync(textDocumentIdentifier, cancellationToken).ConfigureAwait(false); 296var miscDocument = await _lspMiscellaneousFilesWorkspaceProvider.AddMiscellaneousDocumentAsync(uri, trackedDocument.Text, trackedDocument.LanguageId, _logger).ConfigureAwait(false); 498var isTextEquivalent = await AreChecksumsEqualAsync(firstDocument, _trackedDocuments[uriInWorkspace].Text, cancellationToken).ConfigureAwait(false); 512var documentText = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.PerformanceSensitiveAnalyzers (59)
src\Dependencies\Collections\Extensions\IEnumerableExtensions.cs (4)
483builder.Add(await selector(item).ConfigureAwait(false)); 498builder.Add(await selector(item, cancellationToken).ConfigureAwait(false)); 513builder.Add(await selector(item, arg, cancellationToken).ConfigureAwait(false)); 525builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
src\Dependencies\Collections\Extensions\ImmutableArrayExtensions.cs (3)
427builder[i] = await selector(array[i], cancellationToken).ConfigureAwait(false); 445builder[i] = await selector(array[i], arg, cancellationToken).ConfigureAwait(false); 471builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
src\Dependencies\Threading\AsyncBatchingWorkQueue`2.cs (1)
220return (ranToCompletion: true, await ProcessNextBatchAsync().ConfigureAwait(false));
src\Dependencies\Threading\ValueTaskExtensions.cs (2)
237_task.ConfigureAwait(_captureContext).GetAwaiter().OnCompleted(continuation); 247_task.ConfigureAwait(_captureContext).GetAwaiter().UnsafeOnCompleted(continuation);
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Utilities\IAsyncEnumerableExtensions.cs (1)
84while (await reader.WaitToReadAsync(cancellationToken).ConfigureAwait(false))
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Utilities\ProducerConsumer.cs (1)
47while (await reader.WaitToReadAsync(cancellationToken).ConfigureAwait(false))
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\AddImport\AddImportPlacementOptionsProviders.cs (1)
29var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeCleanup\CodeCleanupOptionsProviders.cs (1)
29var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeFixes\ForkingSyntaxEditorBasedCodeFixProvider.cs (1)
99changedRoot, cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeFixes\SyntaxEditorBasedCodeFixProvider.cs (1)
83var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeGeneration\AbstractCodeGenerationService.cs (2)
244var codeGenOptions = await oldDocument.GetCodeGenerationOptionsAsync(cancellationToken).ConfigureAwait(false); 256var addImportsOptions = await newDocument.GetAddImportPlacementOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeGeneration\CleanCodeGenerationOptions.cs (2)
42GenerationOptions = await document.GetCodeGenerationOptionsAsync(cancellationToken).ConfigureAwait(false), 43CleanupOptions = await document.GetCodeCleanupOptionsAsync(cancellationToken).ConfigureAwait(false)
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeGeneration\CodeGenerationOptionsProviders.cs (2)
36var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false); 44var options = await GetCodeGenerationOptionsAsync(document, cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeRefactorings\CodeRefactoringContextExtensions.cs (4)
46var parsedDocument = await ParsedDocument.CreateAsync(context.Document, context.CancellationToken).ConfigureAwait(false); 55var parsedDocument = await ParsedDocument.CreateAsync(context.Document, context.CancellationToken).ConfigureAwait(false); 61var parsedDocument = await ParsedDocument.CreateAsync(document, cancellationToken).ConfigureAwait(false); 84var parsedDocument = await ParsedDocument.CreateAsync(document, cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Editing\ImportAdderService.cs (5)
37var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 120var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 121var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 180var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 183var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Extensions\DocumentExtensions.cs (3)
132var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 136return await ReuseExistingSpeculativeModelAsync(document, node, cancellationToken).ConfigureAwait(false); 225var syntaxTree = await document.GetRequiredSyntaxTreeAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Formatting\DocumentFormattingOptionsProviders.cs (1)
24var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Formatting\LineFormattingOptionsProviders.cs (1)
19var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Formatting\SyntaxFormattingOptionsProviders.cs (1)
22var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\LanguageServices\InitializeParameter\AbstractInitializerParameterService.cs (2)
119var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 123var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\LanguageServices\RemoveUnnecessaryImports\AbstractRemoveUnnecessaryImportsService.cs (2)
27var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 34var currentModel = await current.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\NamingStyles\NamingStylePreferencesProviders.cs (1)
17var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Options\MemberDisplayOptions.cs (1)
52var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\SemanticModelReuse\SemanticModelWorkspaceServiceFactory.SemanticModelWorkspaceService.cs (2)
104return await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 159var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Simplification\AbstractSimplificationService.cs (6)
69var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 96var root = (TCompilationUnitSyntax)await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 107root = (TCompilationUnitSyntax)await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 165var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 236semanticModelForReduce = await newDocument.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 291var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Simplification\SimplifierOptionsProviders.cs (1)
22var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Utilities\ParsedDocument.cs (2)
33var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 34var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Utilities\SemanticDocument.cs (3)
20var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 21var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 22var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Utilities\SyntacticDocument.cs (2)
30var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 31var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.PublicApiAnalyzers (12)
src\Dependencies\Collections\Extensions\IEnumerableExtensions.cs (4)
483builder.Add(await selector(item).ConfigureAwait(false)); 498builder.Add(await selector(item, cancellationToken).ConfigureAwait(false)); 513builder.Add(await selector(item, arg, cancellationToken).ConfigureAwait(false)); 525builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
src\Dependencies\Collections\Extensions\ImmutableArrayExtensions.cs (3)
427builder[i] = await selector(array[i], cancellationToken).ConfigureAwait(false); 445builder[i] = await selector(array[i], arg, cancellationToken).ConfigureAwait(false); 471builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
src\Dependencies\Threading\AsyncBatchingWorkQueue`2.cs (1)
220return (ranToCompletion: true, await ProcessNextBatchAsync().ConfigureAwait(false));
src\Dependencies\Threading\ValueTaskExtensions.cs (2)
237_task.ConfigureAwait(_captureContext).GetAwaiter().OnCompleted(continuation); 247_task.ConfigureAwait(_captureContext).GetAwaiter().UnsafeOnCompleted(continuation);
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Utilities\IAsyncEnumerableExtensions.cs (1)
84while (await reader.WaitToReadAsync(cancellationToken).ConfigureAwait(false))
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Utilities\ProducerConsumer.cs (1)
47while (await reader.WaitToReadAsync(cancellationToken).ConfigureAwait(false))
Microsoft.CodeAnalysis.Remote.ServiceHub (56)
Host\AssetProvider.cs (2)
99AssetPathKind.SolutionCompilationStateChecksums, solutionChecksum, cancellationToken).ConfigureAwait(false); 103AssetPathKind.SolutionStateChecksums, compilationStateChecksums.SolutionState, cancellationToken).ConfigureAwait(false);
Host\RemoteWorkspace.cs (6)
98var (inFlightSolution, solutionTask) = await AcquireSolutionAndIncrementInFlightCountAsync().ConfigureAwait(false); 102return await ProcessSolutionAsync(inFlightSolution, solutionTask).ConfigureAwait(false); 162var result = await implementation(solution).ConfigureAwait(false); 223AssetPathKind.SolutionCompilationStateChecksums, solutionChecksum, cancellationToken).ConfigureAwait(false); 225AssetPathKind.SolutionStateChecksums, newSolutionCompilationChecksums.SolutionState, cancellationToken).ConfigureAwait(false); 227AssetPathKind.SolutionAttributes, newSolutionChecksums.Attributes, cancellationToken).ConfigureAwait(false);
Host\RemoteWorkspace.SolutionCreator.cs (14)
46AssetPathKind.SolutionCompilationStateChecksums, newSolutionChecksum, cancellationToken).ConfigureAwait(false); 48AssetPathKind.SolutionStateChecksums, newSolutionCompilationChecksums.SolutionState, cancellationToken).ConfigureAwait(false); 56AssetPathKind.SolutionAttributes, newSolutionChecksums.Attributes, cancellationToken).ConfigureAwait(false); 75useAsync: true, deserializedAnalyzerReferences, _workspace.Services.SolutionServices, cancellationToken).ConfigureAwait(false); 83AssetPathKind.SolutionFallbackAnalyzerOptions, newSolutionChecksums.FallbackAnalyzerOptions, cancellationToken).ConfigureAwait(false)); 99new(AssetPathKind.SolutionFrozenSourceGeneratedDocumentIdentities, frozenDocumentId), frozenDocumentIdentity, cancellationToken).ConfigureAwait(false); 102new(AssetPathKind.SolutionFrozenSourceGeneratedDocumentText, frozenDocumentId), frozenDocumentTextChecksum, cancellationToken).ConfigureAwait(false); 116AssetPathKind.SolutionSourceGeneratorExecutionVersionMap, newSolutionCompilationChecksums.SourceGeneratorExecutionVersionMap, cancellationToken).ConfigureAwait(false); 329assetPath: projectId, newProjectChecksums.Info, cancellationToken).ConfigureAwait(false)); 348assetPath: project.Id, newProjectChecksums.CompilationOptions, cancellationToken).ConfigureAwait(false))); 355assetPath: project.Id, newProjectChecksums.ParseOptions, cancellationToken).ConfigureAwait(false)); 381useAsync: true, deserializedAnalyzerReferences, _workspace.Services.SolutionServices, cancellationToken).ConfigureAwait(false); 552assetPath: document.Id, newDocumentChecksums.textChecksum, cancellationToken).ConfigureAwait(false); 571assetPath: document.Id, infoChecksum, cancellationToken).ConfigureAwait(false);
Host\RemoteWorkspaceManager.cs (2)
98cancellationToken).ConfigureAwait(false); 117cancellationToken).ConfigureAwait(false);
Host\TestUtils.cs (4)
108AssetPath.FullLookupForTesting, checksum, CancellationToken.None).ConfigureAwait(false))); 119AssetPathKind.SolutionCompilationStateChecksums, solutionChecksum, CancellationToken.None).ConfigureAwait(false); 121AssetPathKind.SolutionStateChecksums, solutionCompilationChecksums.SolutionState, CancellationToken.None).ConfigureAwait(false); 129assetPath: projectId, projectChecksum, CancellationToken.None).ConfigureAwait(false);
Services\AssetSynchronization\RemoteAssetSynchronizationService.cs (2)
117return await serializableSourceText.GetTextAsync(cancellationToken).ConfigureAwait(false); 138return await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Services\BrokeredServiceBase.cs (3)
95cancellationToken).ConfigureAwait(false); 116return await implementation(cancellationToken).ConfigureAwait(false); 142}, c).ConfigureAwait(false);
Services\CodeLensReferences\RemoteCodeLensReferencesService.cs (5)
30var document = await solution.GetDocumentAsync(documentId, includeSourceGenerated: true, cancellationToken).ConfigureAwait(false); 49var syntaxNode = await TryFindNodeAsync(solution, documentId, textSpan, cancellationToken).ConfigureAwait(false); 72var syntaxNode = await TryFindNodeAsync(solution, documentId, textSpan, cancellationToken).ConfigureAwait(false); 90var syntaxNode = await TryFindNodeAsync(solution, documentId, textSpan, cancellationToken).ConfigureAwait(false); 110var syntaxNode = await TryFindNodeAsync(solution, documentId, textSpan, cancellationToken).ConfigureAwait(false);
Services\ConvertTupleToStructCodeRefactoringProvider\RemoteConvertTupleToStructCodeRefactoringService.cs (2)
46solution, cleanedSolution, cancellationToken).ConfigureAwait(false); 85var cleaned = await CodeAction.CleanupDocumentAsync(document, options, cancellationToken).ConfigureAwait(false);
Services\DependentTypeFinder\RemoteDependentTypeFinderService.cs (1)
37var symbol = await typeAndProjectId.TryRehydrateAsync(solution, cancellationToken).ConfigureAwait(false);
Services\DiagnosticAnalyzer\RemoteDiagnosticAnalyzerService.cs (3)
56? solution.GetTextDocument(arguments.DocumentId) ?? await solution.GetSourceGeneratedDocumentAsync(arguments.DocumentId, cancellationToken).ConfigureAwait(false) 78}, cancellationToken).ConfigureAwait(false); 101}, cancellationToken).ConfigureAwait(false);
Services\EditAndContinue\RemoteEditAndContinueService.cs (1)
130var diagnostics = await GetService().GetDocumentDiagnosticsAsync(document, CreateActiveStatementSpanProvider(callbackId), cancellationToken).ConfigureAwait(false);
Services\EncapsulateField\RemoteEncapsulateFieldService.cs (1)
53solution, newSolution, cancellationToken).ConfigureAwait(false);
Services\FindUsages\RemoteFindUsagesService.cs (2)
39solution, cancellationToken).ConfigureAwait(false); 63solution, cancellationToken).ConfigureAwait(false);
Services\NavigationBar\RemoteNavigationBarItemService.cs (1)
27var document = await solution.GetDocumentAsync(documentId, includeSourceGenerated: true, cancellationToken).ConfigureAwait(false);
Services\Renamer\RemoteRenamerService.cs (3)
33solution, cancellationToken).ConfigureAwait(false); 54solution, cancellationToken).ConfigureAwait(false); 80var symbol = await symbolAndProjectId.TryRehydrateAsync(solution, cancellationToken).ConfigureAwait(false);
Services\SemanticClassification\RemoteSemanticClassificationService.Caching.cs (1)
151var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Services\SemanticClassification\RemoteSemanticClassificationService.cs (1)
33var document = solution.GetDocument(documentId) ?? await solution.GetSourceGeneratedDocumentAsync(documentId, cancellationToken).ConfigureAwait(false);
Services\SourceGeneration\RemoteSourceGenerationService.cs (1)
124cancellationToken).ConfigureAwait(false);
Services\SymbolFinder\RemoteSymbolFinderService.cs (1)
45solution, cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.Remote.Workspaces (82)
AbstractAssetProvider.cs (12)
34var solutionCompilationChecksums = await GetAssetAsync<SolutionCompilationStateChecksums>(AssetPathKind.SolutionCompilationStateChecksums, solutionChecksum, cancellationToken).ConfigureAwait(false); 35var solutionChecksums = await GetAssetAsync<SolutionStateChecksums>(AssetPathKind.SolutionStateChecksums, solutionCompilationChecksums.SolutionState, cancellationToken).ConfigureAwait(false); 37var solutionAttributes = await GetAssetAsync<SolutionInfo.SolutionAttributes>(AssetPathKind.SolutionAttributes, solutionChecksums.Attributes, cancellationToken).ConfigureAwait(false); 38await GetAssetAsync<SourceGeneratorExecutionVersionMap>(AssetPathKind.SolutionSourceGeneratorExecutionVersionMap, solutionCompilationChecksums.SourceGeneratorExecutionVersionMap, cancellationToken).ConfigureAwait(false); 58useAsync: true, analyzerReference, solutionServices, cancellationToken).ConfigureAwait(false); 60var fallbackAnalyzerOptions = await GetAssetAsync<ImmutableDictionary<string, StructuredAnalyzerConfigOptions>>(AssetPathKind.SolutionFallbackAnalyzerOptions, solutionChecksums.FallbackAnalyzerOptions, cancellationToken).ConfigureAwait(false); 82var attributes = await GetAssetAsync<ProjectInfo.ProjectAttributes>(new(AssetPathKind.ProjectAttributes, projectId), projectChecksums.Info, cancellationToken).ConfigureAwait(false); 86await GetAssetAsync<CompilationOptions>(new(AssetPathKind.ProjectCompilationOptions, projectId), projectChecksums.CompilationOptions, cancellationToken).ConfigureAwait(false)); 111await parseOptionsTask.ConfigureAwait(false), 115await isolatedAnalyzerReferencesTask.ConfigureAwait(false), 166var attributes = await GetAssetAsync<DocumentInfo.DocumentAttributes>(new(AssetPathKind.DocumentAttributes, documentId), attributeChecksum, cancellationToken).ConfigureAwait(false); 167var serializableSourceText = await GetAssetAsync<SerializableSourceText>(new(AssetPathKind.DocumentText, documentId), textChecksum, cancellationToken).ConfigureAwait(false);
BrokeredServiceConnection.cs (30)
90var proxyRental = await _serviceBrokerClient.GetProxyAsync<TService>(_serviceDescriptor, options, cancellationToken).ConfigureAwait(false); 102using var rental = await RentServiceAsync(cancellationToken).ConfigureAwait(false); 117using var rental = await RentServiceAsync(cancellationToken).ConfigureAwait(false); 118return await invocation(rental.Service, cancellationToken).ConfigureAwait(false); 135using var rental = await RentServiceAsync(cancellationToken).ConfigureAwait(false); 152using var rental = await RentServiceAsync(cancellationToken).ConfigureAwait(false); 153return await invocation(rental.Service, _callbackHandle.Id, cancellationToken).ConfigureAwait(false); 168using var scope = await _solutionAssetStorage.StoreAssetsAsync(compilationState, cancellationToken).ConfigureAwait(false); 169using var rental = await RentServiceAsync(cancellationToken).ConfigureAwait(false); 184using var scope = await _solutionAssetStorage.StoreAssetsAsync(compilationState, cancellationToken).ConfigureAwait(false); 185using var rental = await RentServiceAsync(cancellationToken).ConfigureAwait(false); 186return await invocation(rental.Service, scope.SolutionChecksum, cancellationToken).ConfigureAwait(false); 201using var scope = await _solutionAssetStorage.StoreAssetsAsync(compilationState, projectId, cancellationToken).ConfigureAwait(false); 202using var rental = await RentServiceAsync(cancellationToken).ConfigureAwait(false); 217using var scope = await _solutionAssetStorage.StoreAssetsAsync(compilationState, projectId, cancellationToken).ConfigureAwait(false); 218using var rental = await RentServiceAsync(cancellationToken).ConfigureAwait(false); 219return await invocation(rental.Service, scope.SolutionChecksum, cancellationToken).ConfigureAwait(false); 236using var scope = await _solutionAssetStorage.StoreAssetsAsync(compilationState, cancellationToken).ConfigureAwait(false); 237using var rental = await RentServiceAsync(cancellationToken).ConfigureAwait(false); 255using var scope = await _solutionAssetStorage.StoreAssetsAsync(compilationState, cancellationToken).ConfigureAwait(false); 256using var rental = await RentServiceAsync(cancellationToken).ConfigureAwait(false); 257return await invocation(rental.Service, scope.SolutionChecksum, _callbackHandle.Id, cancellationToken).ConfigureAwait(false); 274using var scope = await _solutionAssetStorage.StoreAssetsAsync(compilationState, projectId, cancellationToken).ConfigureAwait(false); 275using var rental = await RentServiceAsync(cancellationToken).ConfigureAwait(false); 293using var scope = await _solutionAssetStorage.StoreAssetsAsync(compilationState, projectId, cancellationToken).ConfigureAwait(false); 294using var rental = await RentServiceAsync(cancellationToken).ConfigureAwait(false); 295return await invocation(rental.Service, scope.SolutionChecksum, _callbackHandle.Id, cancellationToken).ConfigureAwait(false); 310using var scope1 = await _solutionAssetStorage.StoreAssetsAsync(compilationState1, cancellationToken).ConfigureAwait(false); 311using var scope2 = await _solutionAssetStorage.StoreAssetsAsync(compilationState2, cancellationToken).ConfigureAwait(false); 312using var rental = await RentServiceAsync(cancellationToken).ConfigureAwait(false);
EditAndContinue\ManagedHotReloadLanguageService.cs (7)
67var id = await _solutionSnapshotProvider.RegisterSolutionSnapshotAsync(cancellationToken).ConfigureAwait(false); 84var currentDesignTimeSolution = await GetCurrentDesignTimeSolutionAsync(cancellationToken).ConfigureAwait(false); 170var currentDesignTimeSolution = await GetCurrentDesignTimeSolutionAsync(cancellationToken).ConfigureAwait(false); 260var newSolution = await GetCurrentDesignTimeSolutionAsync(cancellationToken).ConfigureAwait(false); 263? await EditSession.HasChangesAsync(oldSolution, newSolution, sourceFilePath, cancellationToken).ConfigureAwait(false) 264: await EditSession.HasChangesAsync(oldSolution, newSolution, cancellationToken).ConfigureAwait(false); 286var designTimeSolution = await GetCurrentDesignTimeSolutionAsync(cancellationToken).ConfigureAwait(false);
ExternalAccess\Pythia\Api\PythiaRemoteHostClient.cs (8)
43return await connection.TryInvokeAsync(invocation, cancellationToken).ConfigureAwait(false); 49return await connection.TryInvokeAsync(invocation, cancellationToken).ConfigureAwait(false); 57return await connection.TryInvokeAsync(invocation, cancellationToken).ConfigureAwait(false); 63return await connection.TryInvokeAsync(invocation, cancellationToken).ConfigureAwait(false); 71return await connection.TryInvokeAsync(solution, invocation, cancellationToken).ConfigureAwait(false); 77return await connection.TryInvokeAsync(solution, invocation, cancellationToken).ConfigureAwait(false); 85return await connection.TryInvokeAsync(solution, invocation, cancellationToken).ConfigureAwait(false); 91return await connection.TryInvokeAsync(solution, invocation, cancellationToken).ConfigureAwait(false);
ExternalAccess\UnitTesting\Api\UnitTestingRemoteHostClient.cs (8)
43return await connection.TryInvokeAsync(invocation, cancellationToken).ConfigureAwait(false); 49return await connection.TryInvokeAsync(invocation, cancellationToken).ConfigureAwait(false); 57return await connection.TryInvokeAsync(invocation, cancellationToken).ConfigureAwait(false); 63return await connection.TryInvokeAsync(invocation, cancellationToken).ConfigureAwait(false); 71return await connection.TryInvokeAsync(solution, invocation, cancellationToken).ConfigureAwait(false); 77return await connection.TryInvokeAsync(solution, invocation, cancellationToken).ConfigureAwait(false); 85return await connection.TryInvokeAsync(solution, invocation, cancellationToken).ConfigureAwait(false); 91return await connection.TryInvokeAsync(solution, invocation, cancellationToken).ConfigureAwait(false);
RemoteCallback.cs (2)
43rental = await client.GetProxyAsync<T>(serviceDescriptor, cancellationToken).ConfigureAwait(false); 80return await invocation(_callback, cancellationToken).ConfigureAwait(false);
RemoteHostAssetReader.cs (5)
59var responseSolutionChecksum = await ReadChecksumFromPipeReaderAsync(cancellationToken).ConfigureAwait(false); 70var length = await CheckSentinelByteAndReadLengthAsync(cancellationToken).ConfigureAwait(false); 75var fillReadResult = await _pipeReader.ReadAtLeastAsync(length, cancellationToken).ConfigureAwait(false); 99var lengthReadResult = await _pipeReader.ReadAtLeastAsync(HeaderSize, cancellationToken).ConfigureAwait(false); 113var readChecksumResult = await _pipeReader.ReadAtLeastAsync(Checksum.HashSize, cancellationToken).ConfigureAwait(false);
RemoteHostAssetWriter.cs (3)
99await _pipeWriter.FlushAsync(cancellationToken).ConfigureAwait(false); 136await _pipeWriter.FlushAsync(cancellationToken).ConfigureAwait(false); 146await _pipeWriter.FlushAsync(cancellationToken).ConfigureAwait(false);
ServiceBrokerExtensions.cs (6)
16var service = await serviceBroker.GetProxyAsync<TService>(descriptor, cancellationToken).ConfigureAwait(false); 26var service = await serviceBroker.GetProxyAsync<TService>(descriptor, cancellationToken).ConfigureAwait(false); 30return await operation(service, cancellationToken).ConfigureAwait(false); 36var service = await serviceBroker.GetProxyAsync<TService>(descriptor, cancellationToken).ConfigureAwait(false); 40return await operation(service, args, cancellationToken).ConfigureAwait(false); 46var service = await serviceBroker.GetProxyAsync<TService>(descriptor, cancellationToken).ConfigureAwait(false);
SolutionAssetStorage.cs (1)
128return await _solutionAssetStorage._checksumToScope.Single().Value.GetTestAccessor().GetAssetAsync(checksum, cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.ResxSourceGenerator (12)
src\Dependencies\Collections\Extensions\IEnumerableExtensions.cs (4)
483builder.Add(await selector(item).ConfigureAwait(false)); 498builder.Add(await selector(item, cancellationToken).ConfigureAwait(false)); 513builder.Add(await selector(item, arg, cancellationToken).ConfigureAwait(false)); 525builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
src\Dependencies\Collections\Extensions\ImmutableArrayExtensions.cs (3)
427builder[i] = await selector(array[i], cancellationToken).ConfigureAwait(false); 445builder[i] = await selector(array[i], arg, cancellationToken).ConfigureAwait(false); 471builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
src\Dependencies\Threading\AsyncBatchingWorkQueue`2.cs (1)
220return (ranToCompletion: true, await ProcessNextBatchAsync().ConfigureAwait(false));
src\Dependencies\Threading\ValueTaskExtensions.cs (2)
237_task.ConfigureAwait(_captureContext).GetAwaiter().OnCompleted(continuation); 247_task.ConfigureAwait(_captureContext).GetAwaiter().UnsafeOnCompleted(continuation);
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Utilities\IAsyncEnumerableExtensions.cs (1)
84while (await reader.WaitToReadAsync(cancellationToken).ConfigureAwait(false))
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Utilities\ProducerConsumer.cs (1)
47while (await reader.WaitToReadAsync(cancellationToken).ConfigureAwait(false))
Microsoft.CodeAnalysis.Threading.Package (10)
AsyncBatchingWorkQueue`2.cs (1)
220return (ranToCompletion: true, await ProcessNextBatchAsync().ConfigureAwait(false));
src\Dependencies\Collections\Extensions\IEnumerableExtensions.cs (4)
483builder.Add(await selector(item).ConfigureAwait(false)); 498builder.Add(await selector(item, cancellationToken).ConfigureAwait(false)); 513builder.Add(await selector(item, arg, cancellationToken).ConfigureAwait(false)); 525builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
src\Dependencies\Collections\Extensions\ImmutableArrayExtensions.cs (3)
427builder[i] = await selector(array[i], cancellationToken).ConfigureAwait(false); 445builder[i] = await selector(array[i], arg, cancellationToken).ConfigureAwait(false); 471builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
ValueTaskExtensions.cs (2)
237_task.ConfigureAwait(_captureContext).GetAwaiter().OnCompleted(continuation); 247_task.ConfigureAwait(_captureContext).GetAwaiter().UnsafeOnCompleted(continuation);
Microsoft.CodeAnalysis.VisualBasic.EditorFeatures (2)
NavigationBar\VisualBasicEditorNavigationBarItemService.vb (1)
55Dim text = Await destinationDocument.GetValueTextAsync(cancellationToken).ConfigureAwait(False)
NavigationBar\VisualBasicEditorNavigationBarItemService_CodeGeneration.vb (1)
26Dim text = Await document.GetValueTextAsync(cancellationToken).ConfigureAwait(False)
Microsoft.CodeAnalysis.VisualBasic.Features (6)
CodeFixes\GenerateEndConstruct\GenerateEndConstructCodeFixProvider.vb (1)
232Dim text = Await document.GetValueTextAsync(cancellationToken).ConfigureAwait(False)
CodeFixes\MoveToTopOfFile\MoveToTopOfFileCodeFixProvider.MoveToLineCodeAction.vb (1)
33Dim text = Await _document.GetValueTextAsync(cancellationToken).ConfigureAwait(False)
Completion\CompletionProviders\CrefCompletionProvider.vb (1)
84Dim text = Await document.GetValueTextAsync(cancellationToken).ConfigureAwait(False)
Completion\CompletionProviders\VisualBasicSuggestionModeCompletionProvider.vb (1)
34Dim text = Await document.GetValueTextAsync(cancellationToken).ConfigureAwait(False)
Debugging\LocationInfoGetter.vb (1)
42Dim text = Await document.GetValueTextAsync(cancellationToken).ConfigureAwait(False)
Snippets\VisualBasicSnippetFunctionService.vb (1)
49Dim text = Await document.GetValueTextAsync(cancellationToken).ConfigureAwait(False)
Microsoft.CodeAnalysis.Workspaces (321)
CaseCorrection\AbstractCaseCorrectionService.cs (1)
35var semanticModel = await document.ReuseExistingSpeculativeModelAsync(spans.Collapse(), cancellationToken).ConfigureAwait(false);
Classification\AbstractClassificationService.cs (2)
93cancellationToken).ConfigureAwait(false); 126cancellationToken).ConfigureAwait(false);
Classification\Classifier.cs (1)
32var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
Classification\SyntaxClassification\AbstractSyntaxClassificationService.cs (1)
37var semanticModel = await document.GetRequiredNullableDisabledSemanticModelAsync(cancellationToken).ConfigureAwait(false);
CodeActions\CodeAction.cs (2)
469var options = await document.GetCodeCleanupOptionsAsync(cancellationToken).ConfigureAwait(false); 470return await CleanupDocumentAsync(document, options, cancellationToken).ConfigureAwait(false);
CodeActions\CodeAction_Cleanup.cs (5)
144var document = await changedSolution.GetRequiredDocumentAsync(documentId, includeSourceGenerated: true, cancellationToken).ConfigureAwait(false); 149var codeActionOptions = await document.GetCodeCleanupOptionsAsync(cancellationToken).ConfigureAwait(false); 170return await cleanedSolution.GetRequiredDocumentAsync(document.Id, includeSourceGenerated: true, cancellationToken).ConfigureAwait(false); 209var document = await solution.GetRequiredDocumentAsync(documentId, includeSourceGenerated: true, cancellationToken).ConfigureAwait(false); 218var newRoot = await cleanedDocument.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
CodeCleanup\AbstractCodeCleanerService.cs (2)
42var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 483var root = await currentDocument.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
CodeCleanup\CodeCleaner.cs (2)
52var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 62var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
CodeCleanup\Providers\FormatCodeCleanupProvider.cs (1)
23var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
CodeFixes\FixAllOccurrences\BatchFixAllProvider.cs (1)
256var docIdsAndTexts = await docIdsAndMerger.SelectAsArrayAsync(async t => (t.documentId, await t.merger.GetFinalMergedTextAsync(cancellationToken).ConfigureAwait(false))).ConfigureAwait(false);
CodeFixes\FixAllOccurrences\TextChangeMerger.cs (1)
75var oldText = await _oldDocument.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
CodeFixesAndRefactorings\DocumentBasedFixAllProviderHelpers.cs (3)
55.ConfigureAwait(false); 87var newRoot = newDocument.SupportsSyntaxTree ? await newDocument.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false) : null; 88var newText = newDocument.SupportsSyntaxTree ? null : await newDocument.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
CodeRefactorings\SyntaxEditorBasedCodeRefactoringProvider.cs (1)
70var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
Diagnostics\DiagnosticData.cs (2)
152var location = await DataLocation.ConvertLocationAsync(project, cancellationToken).ConfigureAwait(false); 153var additionalLocations = await AdditionalLocations.ConvertLocationsAsync(project, cancellationToken).ConfigureAwait(false);
Diagnostics\Extensions.cs (8)
50?? await project.GetSourceGeneratedDocumentAsync(dataLocation.DocumentId, cancellationToken).ConfigureAwait(false); 54var text = await textDocument.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 56? await document.GetRequiredSyntaxTreeAsync(cancellationToken).ConfigureAwait(false) 351var tree = await document.GetRequiredSyntaxTreeAsync(cancellationToken).ConfigureAwait(false); 360var model = await ((Document)documentAnalysisScope.TextDocument).GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 432var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 519cancellationToken).ConfigureAwait(false); 527return await project.GetSourceGeneratorDiagnosticsAsync(cancellationToken).ConfigureAwait(false);
Editing\ImportAdder.cs (9)
20var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 26var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 34=> await AddImportsFromSyntaxesAsync(document, await GetSpansAsync(document, cancellationToken).ConfigureAwait(false), options, cancellationToken).ConfigureAwait(false); 46=> await AddImportsFromSyntaxesAsync(document, await GetSpansAsync(document, annotation, cancellationToken).ConfigureAwait(false), options, cancellationToken).ConfigureAwait(false); 63var addImportOptions = await document.GetAddImportPlacementOptionsAsync(cancellationToken).ConfigureAwait(false); 71=> await AddImportsFromSyntaxesAsync(document, await GetSpansAsync(document, cancellationToken).ConfigureAwait(false), options, cancellationToken).ConfigureAwait(false); 77=> await AddImportsFromSyntaxesAsync(document, await GetSpansAsync(document, annotation, cancellationToken).ConfigureAwait(false), options, cancellationToken).ConfigureAwait(false); 89=> await AddImportsFromSymbolAnnotationAsync(document, await GetSpansAsync(document, cancellationToken).ConfigureAwait(false), options, cancellationToken).ConfigureAwait(false); 95=> await AddImportsFromSymbolAnnotationAsync(document, await GetSpansAsync(document, annotation, cancellationToken).ConfigureAwait(false), options, cancellationToken).ConfigureAwait(false);
ExtractMethod\ExtractMethodOptions.cs (2)
47CodeGenerationOptions = await document.GetCodeGenerationOptionsAsync(cancellationToken).ConfigureAwait(false), 48CodeCleanupOptions = await document.GetCodeCleanupOptionsAsync(cancellationToken).ConfigureAwait(false),
FindSymbols\Declarations\DeclarationFinder.cs (1)
83project.Solution, reference, checksum: null, cancellationToken).ConfigureAwait(false);
FindSymbols\Declarations\DeclarationFinder_AllDeclarations.cs (2)
45cancellationToken).ConfigureAwait(false); 166var rehydrated = await dehydrated.TryRehydrateAsync(solution, cancellationToken).ConfigureAwait(false);
FindSymbols\Declarations\DeclarationFinder_SourceDeclarations.cs (4)
49cancellationToken).ConfigureAwait(false); 87cancellationToken).ConfigureAwait(false); 120cancellationToken).ConfigureAwait(false); 153cancellationToken).ConfigureAwait(false);
FindSymbols\FindLiterals\FindLiteralsSearchEngine.cs (2)
120document, cancellationToken).ConfigureAwait(false); 141var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
FindSymbols\FindReferences\DependentProjectsFinder.cs (4)
146using (await s_solutionToDependentProjectMapGate.DisposableWaitAsync(cancellationToken).ConfigureAwait(false)) 157using (await s_solutionToDependentProjectMapGate.DisposableWaitAsync(cancellationToken).ConfigureAwait(false)) 344using (await s_metadataIdToAssemblyNameGate.DisposableWaitAsync(cancellationToken).ConfigureAwait(false)) 376using (await s_metadataIdToAssemblyNameGate.DisposableWaitAsync(cancellationToken).ConfigureAwait(false))
FindSymbols\FindReferences\DependentTypeFinder.cs (5)
245var document = await solution.GetRequiredDocumentAsync(documentId, includeSourceGenerated: true, cancellationToken).ConfigureAwait(false); 246var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 262var semanticModel = await GetRequiredSemanticModelAsync(documentId).ConfigureAwait(false); 282var semanticModel = await GetRequiredSemanticModelAsync(documentId).ConfigureAwait(false); 346project.Solution, reference, checksum: null, cancellationToken).ConfigureAwait(false);
FindSymbols\FindReferences\DependentTypeFinder_ProjectIndex.cs (2)
80var sourceGeneratorDocumentStates = await project.Solution.CompilationState.GetSourceGeneratedDocumentStatesAsync(project.State, cancellationToken).ConfigureAwait(false); 91solutionKey, project.State, document, cancellationToken).ConfigureAwait(false);
FindSymbols\FindReferences\DependentTypeFinder_Remote.cs (2)
36cancellationToken).ConfigureAwait(false); 88var rehydrated = await item.TryRehydrateAsync(solution, cancellationToken).ConfigureAwait(false);
FindSymbols\FindReferences\Finders\AbstractReferenceFinder.cs (3)
108if (await predicateAsync(document, value, cancellationToken).ConfigureAwait(false)) 340var info = await SyntaxTreeIndex.GetRequiredIndexAsync(d, c).ConfigureAwait(false); 878var index = await SyntaxTreeIndex.GetRequiredIndexAsync(document, cancellationToken).ConfigureAwait(false);
FindSymbols\FindReferences\Finders\ConstructorInitializerSymbolReferenceFinder.cs (1)
32var index = await SyntaxTreeIndex.GetRequiredIndexAsync(document, cancellationToken).ConfigureAwait(false);
FindSymbols\FindReferences\Finders\ExplicitConversionSymbolReferenceFinder.cs (1)
56var index = await SyntaxTreeIndex.GetRequiredIndexAsync(document, cancellationToken).ConfigureAwait(false);
FindSymbols\FindReferences\Finders\ParameterSymbolReferenceFinder.cs (1)
106var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
FindSymbols\FindReferences\FindReferenceCache.cs (5)
35var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 39var model = await document.GetRequiredNullableDisabledSemanticModelAsync(cancellationToken).ConfigureAwait(false); 40var nullableEnableSemanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 41var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 45var index = await SyntaxTreeIndex.GetRequiredIndexAsync(document, cancellationToken).ConfigureAwait(false);
FindSymbols\FindReferences\FindReferencesSearchEngine.cs (2)
170result.Add((symbol, await ReportGroupSeriallyAsync(symbol, symbolToGroup, cancellationToken).ConfigureAwait(false))); 285var cache = await FindReferenceCache.GetCacheAsync(document, cancellationToken).ConfigureAwait(false);
FindSymbols\FindReferences\FindReferencesSearchEngine.SymbolSet.cs (4)
68var searchSymbols = await MapToAppropriateSymbolsAsync(solution, symbols, cancellationToken).ConfigureAwait(false); 97result.AddIfNotNull(await TryMapToAppropriateSymbolAsync(solution, symbol, cancellationToken).ConfigureAwait(false)); 203var cascaded = await finder.DetermineCascadedSymbolsAsync(symbol, solution, engine._options, cancellationToken).ConfigureAwait(false); 212var mapped = await TryMapToAppropriateSymbolAsync(solution, symbol, cancellationToken).ConfigureAwait(false);
FindSymbols\FindReferences\FindReferencesSearchEngine_FindReferencesInDocuments.cs (5)
108var cache = await FindReferenceCache.GetCacheAsync(document, cancellationToken).ConfigureAwait(false); 187var (matched, candidate, candidateReason) = await HasInheritanceRelationshipAsync(symbol, symbolInfo).ConfigureAwait(false); 193candidate, symbolToGroup, cancellationToken).ConfigureAwait(false); 205if (await HasInheritanceRelationshipSingleAsync(symbol, symbolInfo.Symbol).ConfigureAwait(false)) 210if (await HasInheritanceRelationshipSingleAsync(symbol, candidate).ConfigureAwait(false))
FindSymbols\ReferenceLocationExtensions.cs (1)
36var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
FindSymbols\Shared\AbstractSyntaxIndex.cs (3)
32var index = await GetIndexAsync(solutionKey, project, document, read, create, cancellationToken).ConfigureAwait(false); 88var (textChecksum, textAndDirectivesChecksum) = await GetChecksumsAsync(project, document, cancellationToken).ConfigureAwait(false); 124var syntaxTree = await document.GetSyntaxTreeAsync(cancellationToken).ConfigureAwait(false);
FindSymbols\Shared\AbstractSyntaxIndex_Persistence.cs (2)
72var storage = await storageService.GetStorageAsync(documentKey.Project.Solution, cancellationToken).ConfigureAwait(false); 163var storage = await persistentStorageService.GetStorageAsync(solutionKey, cancellationToken).ConfigureAwait(false);
FindSymbols\SymbolFinder.cs (3)
131var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 212var linkedSyntaxRoot = await linkedDocument.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 218var semanticModel = await linkedDocument.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
FindSymbols\SymbolFinder.FindReferencesServerCallback.cs (2)
48var symbol = await symbolAndProjectId.TryRehydrateAsync(solution, cancellationToken).ConfigureAwait(false); 93solution, cancellationToken).ConfigureAwait(false);
FindSymbols\SymbolFinder_FindLiteralReferences.cs (1)
36cancellationToken).ConfigureAwait(false);
FindSymbols\SymbolFinder_FindReferences_Current.cs (1)
57cancellationToken).ConfigureAwait(false);
FindSymbols\SymbolTree\SymbolTreeInfo_Serialization.cs (3)
56result = await createAsync(checksum).ConfigureAwait(false); 62var storage = await persistentStorageService.GetStorageAsync(solutionKey, cancellationToken).ConfigureAwait(false); 91var storage = await persistentStorageService.GetStorageAsync(solutionKey, cancellationToken).ConfigureAwait(false);
FindSymbols\SymbolTree\SymbolTreeInfoCacheService.cs (1)
200project.Solution, reference, checksum, cancellationToken).ConfigureAwait(false);
Formatting\Formatter.cs (7)
87var (syntaxFormattingOptions, lineFormattingOptions) = await GetFormattingOptionsAsync(document, options, cancellationToken).ConfigureAwait(false); 93options ??= await document.GetSyntaxFormattingOptionsAsync(cancellationToken).ConfigureAwait(false); 94var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 115var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 132var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 136var (formattingOptions, _) = await GetFormattingOptionsAsync(document, optionSet, cancellationToken).ConfigureAwait(false); 362var options = await GetOrganizeImportsOptionsAsync(document, cancellationToken).ConfigureAwait(false);
LanguageServices\FixAllSpanMappingService\AbstractFixAllSpanMappingService.cs (2)
45var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 78var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
LinkedFileDiffMerging\LinkedFileDiffMergingSession.cs (3)
40var newText = await newDocument.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 68var firstSourceText = await firstNewDocument.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 103var firstOldSourceText = await firstOldDocument.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
ObsoleteSymbol\AbstractObsoleteSymbolService.cs (2)
35var semanticModel = await document.GetRequiredNullableDisabledSemanticModelAsync(cancellationToken).ConfigureAwait(false); 36var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
OrganizeImports\OrganizeImportsOptionsProviders.cs (1)
25var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
ReassignedVariable\AbstractReassignedVariableService.cs (1)
46var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
Recommendations\Recommender.cs (1)
51var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
Remote\RemoteArguments.cs (3)
175var document = await solution.GetRequiredDocumentAsync(this.Document, includeSourceGenerated: true, cancellationToken).ConfigureAwait(false); 176var syntaxTree = await document.GetRequiredSyntaxTreeAsync(cancellationToken).ConfigureAwait(false); 195var symbol = await Alias.TryRehydrateAsync(solution, cancellationToken).ConfigureAwait(false);
Remote\RemoteHostClient.cs (14)
66return await connection.TryInvokeAsync(invocation, cancellationToken).ConfigureAwait(false); 75return await connection.TryInvokeAsync(invocation, cancellationToken).ConfigureAwait(false); 87return await connection.TryInvokeAsync(invocation, cancellationToken).ConfigureAwait(false); 97return await connection.TryInvokeAsync(invocation, cancellationToken).ConfigureAwait(false); 118return await connection.TryInvokeAsync(compilationState, invocation, cancellationToken).ConfigureAwait(false); 128return await connection.TryInvokeAsync(solution, invocation, cancellationToken).ConfigureAwait(false); 146return await connection.TryInvokeAsync(project, invocation, cancellationToken).ConfigureAwait(false); 157return await connection.TryInvokeAsync(compilationState, projectId, invocation, cancellationToken).ConfigureAwait(false); 173return await connection.TryInvokeAsync(project, invocation, cancellationToken).ConfigureAwait(false); 186return await connection.TryInvokeAsync(solution, invocation, cancellationToken).ConfigureAwait(false); 197return await connection.TryInvokeAsync(solution, invocation, cancellationToken).ConfigureAwait(false); 216return await connection.TryInvokeAsync(project, invocation, cancellationToken).ConfigureAwait(false); 233return await connection.TryInvokeAsync(project, invocation, cancellationToken).ConfigureAwait(false); 246return await connection.TryInvokeAsync(solution1, solution2, invocation, cancellationToken).ConfigureAwait(false);
Remote\RemoteUtilities.cs (2)
58var oldText = await oldSolution.GetDocument(tuple.documentId).GetValueTextAsync(cancellationToken).ConfigureAwait(false); 62.ConfigureAwait(false);
Rename\ConflictEngine\ConflictResolver.cs (1)
72cancellationToken).ConfigureAwait(false);
Rename\ConflictEngine\ConflictResolver.Session.cs (12)
218await conflictResolution.CurrentSolution.GetRequiredDocument(_documentIdOfRenameSymbolDeclaration).GetRequiredSemanticModelAsync(_cancellationToken).ConfigureAwait(false), 323var syntaxRoot = await newDocument.GetRequiredSyntaxRootAsync(_cancellationToken).ConfigureAwait(false); 349var syntaxRoot = await newDocument.GetRequiredSyntaxRootAsync(_cancellationToken).ConfigureAwait(false); 351var baseSyntaxTree = await baseDocument.GetRequiredSyntaxTreeAsync(_cancellationToken).ConfigureAwait(false); 352var baseRoot = await baseDocument.GetRequiredSyntaxRootAsync(_cancellationToken).ConfigureAwait(false); 375newDocumentSemanticModel ??= await newDocument.GetRequiredSemanticModelAsync(_cancellationToken).ConfigureAwait(false); 441var syntaxRoot = await newDocument.GetRequiredSyntaxRootAsync(_cancellationToken).ConfigureAwait(false); 443var baseSyntaxTree = await baseDocument.GetRequiredSyntaxTreeAsync(_cancellationToken).ConfigureAwait(false); 538.SelectAsArrayAsync(static (symbol, solution, cancellationToken) => GetSymbolLocationAsync(solution, symbol, cancellationToken), solution, _cancellationToken).ConfigureAwait(false)) 583var newLocation = await GetSymbolLocationAsync(solution, symbol, _cancellationToken).ConfigureAwait(false); 744var info = await SyntaxTreeIndex.GetRequiredIndexAsync(document, _cancellationToken).ConfigureAwait(false); 791var semanticModel = await document.GetRequiredSemanticModelAsync(_cancellationToken).ConfigureAwait(false);
Rename\ConflictEngine\MutableConflictResolution.cs (1)
74var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
Rename\ConflictEngine\RenamedSpansTracker.cs (2)
156var cleanupOptions = await document.GetCodeCleanupOptionsAsync(cancellationToken).ConfigureAwait(false); 174var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
Rename\IRemoteRenamerService.cs (6)
91var tree = await document.GetRequiredSyntaxTreeAsync(cancellation).ConfigureAwait(false); 122static (loc, solution, cancellationToken) => loc.RehydrateAsync(solution, cancellationToken), solution, cancellationToken).ConfigureAwait(false); 125static (loc, solution, cancellationToken) => loc.RehydrateAsync(solution, cancellationToken), solution, cancellationToken).ConfigureAwait(false); 128static (sym, solution, cancellationToken) => sym.TryRehydrateAsync(solution, cancellationToken), solution, cancellationToken).ConfigureAwait(false); 166locBuilder.Add(await loc.RehydrateAsync(solution, cancellationToken).ConfigureAwait(false)); 247var documentTextChanges = await RemoteUtilities.GetDocumentTextChangesAsync(OldSolution, _newSolutionWithoutRenamedDocument, cancellationToken).ConfigureAwait(false);
Rename\LightweightRenameLocations.cs (4)
52static (sym, solution, cancellationToken) => sym.TryRehydrateAsync(solution, cancellationToken), Solution, cancellationToken).ConfigureAwait(false); 58static (loc, solution, cancellationToken) => loc.RehydrateAsync(solution, cancellationToken), Solution, cancellationToken).ConfigureAwait(false); 90cancellationToken).ConfigureAwait(false); 94var rehydratedLocations = await result.Value.RehydrateLocationsAsync(solution, cancellationToken).ConfigureAwait(false);
Rename\Renamer.cs (1)
172cancellationToken).ConfigureAwait(false);
Rename\Renamer.RenameSymbolDocumentAction.cs (3)
50var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 71var syntaxRoot = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 106var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
Rename\SymbolicRenameLocations.cs (1)
141cancellationToken).ConfigureAwait(false));
Rename\SymbolicRenameLocations.ReferenceProcessing.cs (2)
370var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 388var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
Serialization\SerializableSourceText.cs (1)
240=> TextAndVersion.Create(await this.SerializableSourceText.GetTextAsync(cancellationToken).ConfigureAwait(false), _version);
Shared\Extensions\DocumentExtensions.cs (1)
16var result = await SyntaxTreeIndex.GetIndexAsync(document, loadOnly: false, cancellationToken).ConfigureAwait(false);
Shared\Extensions\ProjectExtensions.cs (1)
51var document = await project.GetSourceGeneratedDocumentAsync(documentId, cancellationToken).ConfigureAwait(false);
Shared\TestHooks\AsynchronousOperationListenerProvider.cs (1)
136CancellationToken.None).ConfigureAwait(false);
Simplification\Simplifier.cs (8)
74var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 119var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 159var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 167var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 187var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 195var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 247var options = await document.GetSimplifierOptionsAsync(cancellationToken).ConfigureAwait(false); 248var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Compilers\Core\Portable\Hashing\NonCryptographicHashAlgorithm.cs (1)
165int read = await stream.ReadAsync(buffer.AsMemory(), cancellationToken).ConfigureAwait(false);
src\Dependencies\Collections\Extensions\IEnumerableExtensions.cs (4)
483builder.Add(await selector(item).ConfigureAwait(false)); 498builder.Add(await selector(item, cancellationToken).ConfigureAwait(false)); 513builder.Add(await selector(item, arg, cancellationToken).ConfigureAwait(false)); 525builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
src\Dependencies\Collections\Extensions\ImmutableArrayExtensions.cs (3)
427builder[i] = await selector(array[i], cancellationToken).ConfigureAwait(false); 445builder[i] = await selector(array[i], arg, cancellationToken).ConfigureAwait(false); 471builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
src\Dependencies\Threading\AsyncBatchingWorkQueue`2.cs (1)
220return (ranToCompletion: true, await ProcessNextBatchAsync().ConfigureAwait(false));
src\Dependencies\Threading\ValueTaskExtensions.cs (2)
237_task.ConfigureAwait(_captureContext).GetAwaiter().OnCompleted(continuation); 247_task.ConfigureAwait(_captureContext).GetAwaiter().UnsafeOnCompleted(continuation);
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Utilities\IAsyncEnumerableExtensions.cs (1)
84while (await reader.WaitToReadAsync(cancellationToken).ConfigureAwait(false))
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Utilities\ProducerConsumer.cs (1)
47while (await reader.WaitToReadAsync(cancellationToken).ConfigureAwait(false))
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\AddImport\AddImportPlacementOptionsProviders.cs (1)
29var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeCleanup\CodeCleanupOptionsProviders.cs (1)
29var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeFixes\ForkingSyntaxEditorBasedCodeFixProvider.cs (1)
99changedRoot, cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeFixes\SyntaxEditorBasedCodeFixProvider.cs (1)
83var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeGeneration\AbstractCodeGenerationService.cs (2)
244var codeGenOptions = await oldDocument.GetCodeGenerationOptionsAsync(cancellationToken).ConfigureAwait(false); 256var addImportsOptions = await newDocument.GetAddImportPlacementOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeGeneration\CleanCodeGenerationOptions.cs (2)
42GenerationOptions = await document.GetCodeGenerationOptionsAsync(cancellationToken).ConfigureAwait(false), 43CleanupOptions = await document.GetCodeCleanupOptionsAsync(cancellationToken).ConfigureAwait(false)
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeGeneration\CodeGenerationOptionsProviders.cs (2)
36var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false); 44var options = await GetCodeGenerationOptionsAsync(document, cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeRefactorings\CodeRefactoringContextExtensions.cs (4)
46var parsedDocument = await ParsedDocument.CreateAsync(context.Document, context.CancellationToken).ConfigureAwait(false); 55var parsedDocument = await ParsedDocument.CreateAsync(context.Document, context.CancellationToken).ConfigureAwait(false); 61var parsedDocument = await ParsedDocument.CreateAsync(document, cancellationToken).ConfigureAwait(false); 84var parsedDocument = await ParsedDocument.CreateAsync(document, cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Editing\ImportAdderService.cs (5)
37var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 120var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 121var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 180var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 185var model = await document.GetRequiredNullableDisabledSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Extensions\DocumentExtensions.cs (2)
132var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 136return await ReuseExistingSpeculativeModelAsync(document, node, cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Extensions\ISolutionExtensions.cs (2)
93=> (await solution.GetDocumentAsync(documentId, includeSourceGenerated, cancellationToken).ConfigureAwait(false)) ?? throw CreateDocumentNotFoundException(); 96=> (await solution.GetTextDocumentAsync(documentId, cancellationToken).ConfigureAwait(false)) ?? throw CreateDocumentNotFoundException();
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Formatting\DocumentFormattingOptionsProviders.cs (1)
24var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Formatting\LineFormattingOptionsProviders.cs (1)
19var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Formatting\SyntaxFormattingOptionsProviders.cs (1)
22var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\LanguageServices\InitializeParameter\AbstractInitializerParameterService.cs (2)
119var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 123var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\LanguageServices\RemoveUnnecessaryImports\AbstractRemoveUnnecessaryImportsService.cs (2)
27var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 34var currentModel = await current.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\NamingStyles\NamingStylePreferencesProviders.cs (1)
17var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Options\MemberDisplayOptions.cs (1)
52var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\SemanticModelReuse\SemanticModelWorkspaceServiceFactory.SemanticModelWorkspaceService.cs (2)
104return await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 159var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Simplification\AbstractSimplificationService.cs (6)
69var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 96var root = (TCompilationUnitSyntax)await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 107root = (TCompilationUnitSyntax)await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 165var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 236semanticModelForReduce = await newDocument.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 291var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Simplification\SimplifierOptionsProviders.cs (1)
22var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Utilities\ParsedDocument.cs (2)
33var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 34var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Utilities\SemanticDocument.cs (3)
20var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 21var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 22var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Utilities\SyntacticDocument.cs (2)
30var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 31var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
Storage\AbstractPersistentStorageService.cs (5)
57using (await _lock.DisposableWaitAsync(cancellationToken).ConfigureAwait(false)) 61_currentPersistentStorage = await CreatePersistentStorageAsync(solutionKey, workingFolder, faultInjector, cancellationToken).ConfigureAwait(false); 74var result = await TryCreatePersistentStorageAsync(solutionKey, workingFolderPath, faultInjector, cancellationToken).ConfigureAwait(false) ?? 75await TryCreatePersistentStorageAsync(solutionKey, workingFolderPath, faultInjector, cancellationToken).ConfigureAwait(false); 92return await TryOpenDatabaseAsync(solutionKey, workingFolderPath, databaseFilePath, faultInjector, cancellationToken).ConfigureAwait(false);
Workspace\IsolatedAnalyzerReferenceSet.Core.cs (3)
214cancellationToken).ConfigureAwait(false); 236? await s_gate.DisposableWaitAsync(cancellationToken).ConfigureAwait(false) 251? await s_gate.DisposableWaitAsync(cancellationToken).ConfigureAwait(false)
Workspace\ProjectSystem\ProjectSystemProject.BatchingDocumentCollection.cs (2)
399using (await _project._gate.DisposableWaitAsync().ConfigureAwait(false)) 478using (await _project._gate.DisposableWaitAsync(cancellationToken).ConfigureAwait(false))
Workspace\ProjectSystem\ProjectSystemProject.cs (2)
535using (await _gate.DisposableWaitAsync(cancellationToken).ConfigureAwait(false)) 573using (useAsync ? await _gate.DisposableWaitAsync().ConfigureAwait(false) : _gate.DisposableWait())
Workspace\ProjectSystem\ProjectSystemProjectFactory.cs (5)
184var disposableBatchScope = await project.CreateBatchScopeAsync(CancellationToken.None).ConfigureAwait(false); 233using (await _gate.DisposableWaitAsync(cancellationToken).ConfigureAwait(false)) 244using (useAsync ? await _gate.DisposableWaitAsync().ConfigureAwait(false) : _gate.DisposableWait()) 292using (useAsync ? await _gate.DisposableWaitAsync().ConfigureAwait(false) : _gate.DisposableWait()) 340CancellationToken.None).ConfigureAwait(false);
Workspace\Solution\AnalyzerConfigDocumentState.cs (1)
27asynchronousComputeFunction: static async (self, cancellationToken) => AnalyzerConfig.Parse(await self.GetTextAsync(cancellationToken).ConfigureAwait(false), self.FilePath),
Workspace\Solution\Document.cs (3)
350var syntaxTree = await this.GetRequiredSyntaxTreeAsync(cancellationToken).ConfigureAwait(false); 604var options = await arg.self.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false); 616return await provider.GetOptionsAsync(DocumentState, cancellationToken).ConfigureAwait(false);
Workspace\Solution\DocumentState.cs (2)
106var text = await this.GetTextAsync(cancellationToken).ConfigureAwait(false); 640return await GetTextVersionAsync(cancellationToken).ConfigureAwait(false);
Workspace\Solution\Project.cs (8)
298return await GetSourceGeneratedDocumentAsync(documentId, cancellationToken).ConfigureAwait(false); 310return await GetSourceGeneratedDocumentAsync(documentId, cancellationToken).ConfigureAwait(false); 318var generatedDocumentStates = await Solution.CompilationState.GetSourceGeneratedDocumentStatesAsync(this.State, cancellationToken).ConfigureAwait(false); 330foreach (var document in await GetSourceGeneratedDocumentsAsync(cancellationToken).ConfigureAwait(false)) 350var generatedDocumentStates = await Solution.CompilationState.GetSourceGeneratedDocumentStatesAsync(State, cancellationToken).ConfigureAwait(false); 472var index = await SyntaxTreeIndex.GetRequiredIndexAsync(d, cancellationToken).ConfigureAwait(false); 482var index = await TopLevelSyntaxTreeIndex.GetRequiredIndexAsync(d, cancellationToken).ConfigureAwait(false); 838var documentId = await State.GetDocumentIdAsync(contentHash, cancellationToken).ConfigureAwait(false);
Workspace\Solution\ProjectState.cs (10)
120_lazyLatestDocumentVersion = AsyncLazy.Create(static async (self, c) => await ComputeLatestDocumentVersionAsync(self.DocumentStates, self.AdditionalDocumentStates, c).ConfigureAwait(false), arg: this); 143var text = await documentState.GetTextAsync(cancellationToken).ConfigureAwait(false); 234var version = await state.GetTextVersionAsync(cancellationToken).ConfigureAwait(false); 243var version = await state.GetTextVersionAsync(cancellationToken).ConfigureAwait(false); 275var newVersion = await newDocument.GetTopLevelChangeTextVersionAsync(cancellationToken).ConfigureAwait(false); 290var version = await state.GetTopLevelChangeTextVersionAsync(cancellationToken).ConfigureAwait(false); 298var version = await state.GetTopLevelChangeTextVersionAsync(cancellationToken).ConfigureAwait(false); 1095await ComputeLatestDocumentVersionAsync(arg.newDocumentStates, arg.newAdditionalDocumentStates, cancellationToken).ConfigureAwait(false), 1103var finalVersion = await newDocuments[0].GetTextVersionAsync(cancellationToken).ConfigureAwait(false); 1105finalVersion = finalVersion.GetNewerVersion(await newDocuments[i].GetTextVersionAsync(cancellationToken).ConfigureAwait(false));
Workspace\Solution\ProjectState_Checksum.cs (3)
74documentChecksums: await documentChecksumsTask.ConfigureAwait(false), 75await additionalDocumentChecksumsTask.ConfigureAwait(false), 76await analyzerConfigDocumentChecksumsTask.ConfigureAwait(false));
Workspace\Solution\SolutionCompilationState.RegularCompilationTracker.cs (1)
265using (await buildLock.DisposableWaitAsync(cancellationToken).ConfigureAwait(false))
Workspace\Solution\SolutionCompilationState.RegularCompilationTracker_Generators.cs (6)
44static (state, cancellationToken) => state.GetSyntaxTreeAsync(cancellationToken), cancellationToken).ConfigureAwait(false); 106cancellationToken).ConfigureAwait(false); 172cancellationToken).ConfigureAwait(false); 226static (state, cancellationToken) => state.GetSyntaxTreeAsync(cancellationToken), cancellationToken).ConfigureAwait(false)); 262treesToRemove.Add(await documentState.Value.GetSyntaxTreeAsync(cancellationToken).ConfigureAwait(false)); 368static (state, cancellationToken) => state.GetSyntaxTreeAsync(cancellationToken), cancellationToken).ConfigureAwait(false));
Workspace\Solution\SolutionCompilationState.TranslationAction_Actions.cs (5)
40await oldState.GetSyntaxTreeAsync(cancellationToken).ConfigureAwait(false), 41await newState.GetSyntaxTreeAsync(cancellationToken).ConfigureAwait(false)); 146syntaxTrees.Add(await document.GetSyntaxTreeAsync(cancellationToken).ConfigureAwait(false)); 185callback((document, await document.GetSyntaxTreeAsync(cancellationToken).ConfigureAwait(false))), 213syntaxTrees.Add(await documentState.GetSyntaxTreeAsync(cancellationToken).ConfigureAwait(false));
Workspace\Solution\SolutionCompilationState.WithFrozenSourceGeneratedDocumentsCompilationTracker.cs (4)
122compilationState, withFrozenSourceGeneratedDocuments: true, cancellationToken).ConfigureAwait(false); 129var replacementSyntaxTree = await replacementState.GetSyntaxTreeAsync(cancellationToken).ConfigureAwait(false); 135var existingSyntaxTree = await existingState.GetSyntaxTreeAsync(cancellationToken).ConfigureAwait(false); 163compilationState, withFrozenSourceGeneratedDocuments, cancellationToken).ConfigureAwait(false);
Workspace\Solution\SolutionCompilationState_Checksum.cs (1)
129var frozenSourceGeneratedDocumentTexts = await FrozenSourceGeneratedDocumentStates.GetDocumentChecksumsAndIdsAsync(cancellationToken).ConfigureAwait(false);
Workspace\Solution\SolutionCompilationState_SourceGenerators.cs (1)
146cancellationToken).ConfigureAwait(false);
Workspace\Solution\StateChecksums.cs (1)
530var text = await SerializableSourceText.FromTextDocumentStateAsync(state, cancellationToken).ConfigureAwait(false);
Workspace\Solution\TextDocument.cs (1)
93=> await State.GetTextVersionAsync(cancellationToken).ConfigureAwait(false);
Workspace\Solution\TextDocumentState.cs (2)
134var textAndVersion = await GetTextAndVersionAsync(cancellationToken).ConfigureAwait(false); 203var textAndVersion = await GetTextAndVersionAsync(cancellationToken).ConfigureAwait(false);
Workspace\Solution\TextDocumentState_Checksum.cs (1)
40var serializableText = await SerializableSourceText.FromTextDocumentStateAsync(this, cancellationToken).ConfigureAwait(false);
Workspace\Solution\VersionSource\LoadableTextAndVersionSource.cs (1)
73using (await _gate.DisposableWaitAsync(cancellationToken).ConfigureAwait(false))
Workspace\Solution\VersionSource\RecoverableTextAndVersion.cs (2)
128var recoverableText = await GetRecoverableTextAsync(useAsync: true, options, cancellationToken).ConfigureAwait(false); 134var recoverableText = await GetRecoverableTextAsync(useAsync: true, options, cancellationToken).ConfigureAwait(false);
Workspace\Solution\VersionSource\RecoverableTextAndVersion.RecoverableText.cs (1)
117using (await Gate.DisposableWaitAsync(cancellationToken).ConfigureAwait(false))
Workspace\Workspace.cs (2)
284cancellationToken).ConfigureAwait(false); 530using (useAsync ? await _serializationLock.DisposableWaitAsync(cancellationToken).ConfigureAwait(false) : _serializationLock.DisposableWait(cancellationToken))
Workspace\Workspace_SourceGeneration.cs (1)
57cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.Workspaces.MSBuild (1)
src\Workspaces\MSBuild\BuildHost\Rpc\Contracts\TextReaderExtensions.cs (1)
26return await streamReader.ReadLineAsync(cancellationToken).ConfigureAwait(false);
Microsoft.CodeAnalysis.Workspaces.MSBuild.BuildHost (9)
Build\ProjectBuildManager.cs (1)
334using (await s_buildManagerLock.DisposableWaitAsync(cancellationToken).ConfigureAwait(false))
Rpc\RpcServer.cs (1)
175using (await _sendingStreamSemaphore.DisposableWaitAsync().ConfigureAwait(false))
src\Dependencies\Collections\Extensions\IEnumerableExtensions.cs (4)
483builder.Add(await selector(item).ConfigureAwait(false)); 498builder.Add(await selector(item, cancellationToken).ConfigureAwait(false)); 513builder.Add(await selector(item, arg, cancellationToken).ConfigureAwait(false)); 525builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
src\Dependencies\Collections\Extensions\ImmutableArrayExtensions.cs (3)
427builder[i] = await selector(array[i], cancellationToken).ConfigureAwait(false); 445builder[i] = await selector(array[i], arg, cancellationToken).ConfigureAwait(false); 471builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
Microsoft.DotNet.Helix.Client (47)
generated-code\Aggregate.cs (11)
216using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false)) 311using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false)) 416using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false)) 528using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false)) 635using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false)) 777using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false)) 871using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false)) 946using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false)) 1063using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false)) 1183using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false)) 1264using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false))
generated-code\Analysis.cs (2)
118using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false)) 210using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false))
generated-code\Information.cs (3)
83using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false)) 157using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false)) 226using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false))
generated-code\Job.cs (8)
139using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false)) 238using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false)) 313using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false)) 388using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false)) 463using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false)) 538using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false)) 618using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false)) 684using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false))
generated-code\LogSearch.cs (2)
105using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false)) 195using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false))
generated-code\Machine.cs (2)
94using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false)) 166using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false))
generated-code\ScaleSets.cs (2)
78using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false)) 152using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false))
generated-code\Storage.cs (3)
77using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false)) 163using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false)) 249using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false))
generated-code\Telemetry.cs (8)
136using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false)) 226using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false)) 327using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false)) 408using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false)) 514using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false)) 611using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false)) 708using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false)) 805using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false))
generated-code\WorkItem.cs (5)
112using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false)) 193using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false)) 274using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false)) 344using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false)) 425using (var _res = await Client.SendAsync(_req, cancellationToken).ConfigureAwait(false))
HelixApiTokenAuthenticationPolicy.cs (1)
29var token = await _credential.GetTokenAsync(new TokenRequestContext(Array.Empty<string>(), message.Request.ClientRequestId), message.CancellationToken).ConfigureAwait(false);
Microsoft.DotNet.Internal.SymbolHelper (2)
SymbolUploadHelper.cs (2)
430AccessToken token = await _credential.GetTokenAsync(new TokenRequestContext([AzureDevOpsResource]), ct).ConfigureAwait(false); 505string? line = await vt.ConfigureAwait(false);
Microsoft.Extensions.AI.Abstractions (7)
Functions\AIFunctionFactory.cs (7)
577ReflectionInvoke(FunctionDescriptor.Method, target, args), cancellationToken).ConfigureAwait(true); 885return await marshalResult(null, null, cancellationToken).ConfigureAwait(true); 905return await marshalResult(null, null, cancellationToken).ConfigureAwait(true); 930return await marshalResult(result, taskResultGetter.ReturnType, cancellationToken).ConfigureAwait(true); 939return await SerializeResultAsync(result, returnTypeInfo, cancellationToken).ConfigureAwait(true); 957return await marshalResult(result, asTaskResultGetter.ReturnType, cancellationToken).ConfigureAwait(true); 967return await SerializeResultAsync(result, returnTypeInfo, cancellationToken).ConfigureAwait(true);
Microsoft.Extensions.AI.Evaluation (3)
CompositeEvaluator.cs (1)
143cancellationToken).ConfigureAwait(false);
Utilities\TaskExtensions.cs (1)
90yield return await task.ConfigureAwait(false);
Utilities\TimingHelper.cs (1)
104result = await operation().ConfigureAwait(false);
Microsoft.Extensions.AI.Evaluation.Console (1)
Utilities\LoggerExtensions.cs (1)
128return await operation().ConfigureAwait(false);
Microsoft.Extensions.AI.Evaluation.NLP (1)
src\Libraries\Microsoft.Extensions.AI.Evaluation\Utilities\TimingHelper.cs (1)
104result = await operation().ConfigureAwait(false);
Microsoft.Extensions.AI.Evaluation.Quality (14)
CoherenceEvaluator.cs (1)
97cancellationToken)).ConfigureAwait(false);
CompletenessEvaluator.cs (1)
102cancellationToken)).ConfigureAwait(false);
EquivalenceEvaluator.cs (1)
103cancellationToken)).ConfigureAwait(false);
FluencyEvaluator.cs (1)
89cancellationToken)).ConfigureAwait(false);
GroundednessEvaluator.cs (1)
103cancellationToken)).ConfigureAwait(false);
IntentResolutionEvaluator.cs (2)
147cancellationToken)).ConfigureAwait(false); 352cancellationToken).ConfigureAwait(false);
RelevanceEvaluator.cs (1)
102cancellationToken)).ConfigureAwait(false);
RelevanceTruthAndCompletenessEvaluator.cs (2)
121cancellationToken)).ConfigureAwait(false); 297cancellationToken).ConfigureAwait(false);
RetrievalEvaluator.cs (1)
118cancellationToken)).ConfigureAwait(false);
src\Libraries\Microsoft.Extensions.AI.Evaluation\Utilities\TimingHelper.cs (1)
104result = await operation().ConfigureAwait(false);
TaskAdherenceEvaluator.cs (1)
146cancellationToken)).ConfigureAwait(false);
ToolCallAccuracyEvaluator.cs (1)
146cancellationToken)).ConfigureAwait(false);
Microsoft.Extensions.AI.Evaluation.Reporting (4)
ReportingConfiguration.cs (1)
237cancellationToken).ConfigureAwait(false);
ScenarioRun.cs (1)
165cancellationToken).ConfigureAwait(false);
Storage\DiskBasedResponseCache.CacheEntry.cs (1)
60cancellationToken).ConfigureAwait(false) ??
Storage\DiskBasedResultStore.cs (1)
72cancellationToken).ConfigureAwait(false);
Microsoft.Extensions.AI.Evaluation.Reporting.Azure (4)
Storage\AzureStorageResponseCache.CacheEntry.cs (1)
66cancellationToken).ConfigureAwait(false)
Storage\AzureStorageResponseCache.cs (2)
69await CheckPathsAsync(key, cancellationToken).ConfigureAwait(false); 117await CheckPathsAsync(key, cancellationToken).ConfigureAwait(false);
Storage\AzureStorageResultStore.cs (1)
118cancellationToken).ConfigureAwait(false)
Microsoft.Extensions.AI.Evaluation.Safety (19)
CodeVulnerabilityEvaluator.cs (1)
63cancellationToken: cancellationToken).ConfigureAwait(false);
ContentHarmEvaluator.cs (1)
65cancellationToken: cancellationToken).ConfigureAwait(false);
ContentSafetyChatClient.cs (2)
76cancellationToken).ConfigureAwait(false); 109cancellationToken).ConfigureAwait(false);
ContentSafetyEvaluator.cs (1)
149cancellationToken: cancellationToken)).ConfigureAwait(false);
ContentSafetyService.cs (9)
136await GetServiceUrlAsync(annotationTask, evaluatorName, cancellationToken).ConfigureAwait(false); 143cancellationToken).ConfigureAwait(false); 149cancellationToken).ConfigureAwait(false); 172await GetServiceDiscoveryUrlAsync(evaluatorName, cancellationToken).ConfigureAwait(false); 205cancellationToken: cancellationToken).ConfigureAwait(false); 253cancellationToken: cancellationToken).ConfigureAwait(false); 308cancellationToken).ConfigureAwait(false); 363cancellationToken: cancellationToken).ConfigureAwait(false); 432cancellationToken).ConfigureAwait(false);
GroundednessProEvaluator.cs (1)
64cancellationToken: cancellationToken).ConfigureAwait(false);
ProtectedMaterialEvaluator.cs (2)
86cancellationToken: cancellationToken).ConfigureAwait(false); 100cancellationToken: cancellationToken).ConfigureAwait(false);
src\Libraries\Microsoft.Extensions.AI.Evaluation\Utilities\TimingHelper.cs (1)
104result = await operation().ConfigureAwait(false);
UngroundedAttributesEvaluator.cs (1)
68cancellationToken: cancellationToken).ConfigureAwait(false);
Microsoft.Extensions.AI.Ollama (1)
OllamaChatClient.cs (1)
155while ((await streamReader.ReadLineAsync(cancellationToken).ConfigureAwait(false)) is { } line)
Microsoft.Extensions.AI.OpenAI (4)
OpenAIAssistantChatClient.cs (1)
88(RunCreationOptions runOptions, List<FunctionResultContent>? toolResults) = await CreateRunOptionsAsync(messages, options, cancellationToken).ConfigureAwait(false);
src\Shared\ServerSentEvents\SseParser_1.cs (3)
205while (await FillLineBufferAsync(cancellationToken).ConfigureAwait(false) != 0 && _lineLength < Utf8Bom.Length) ; 255_ = await FillLineBufferAsync(cancellationToken).ConfigureAwait(false); 527.ConfigureAwait(false);
Microsoft.Extensions.Caching.Hybrid (6)
Internal\DefaultHybridCache.L2.cs (2)
73BufferChunk result = await pending.ConfigureAwait(false) 147BufferChunk buffer = await GetFromL2DirectAsync(TagKeyPrefix + tag, cts.Token).ConfigureAwait(false);
Internal\DefaultHybridCache.StampedeStateT.cs (3)
196result = await Cache.GetFromL2DirectAsync(Key.Key, SharedToken).ConfigureAwait(false); 239if (pendingTags.IsEmpty || !await Cache.IsAnyTagExpiredAsync(pendingTags, CacheItem.CreationTimestamp).ConfigureAwait(false)) 274newValue = await _underlying!(_state!, SharedToken).ConfigureAwait(false);
Internal\DefaultHybridCache.TagInvalidation.cs (1)
155if (await @this.IsTagExpiredAsync(tags[i], timestamp).ConfigureAwait(false))
Microsoft.Extensions.Caching.StackExchangeRedis (4)
RedisCache.cs (4)
216var cache = await ConnectAsync(token).ConfigureAwait(false); 434var cache = await ConnectAsync(token).ConfigureAwait(false); 489var cache = await ConnectAsync(token).ConfigureAwait(false); 753var cache = await ConnectAsync(token).ConfigureAwait(false);
Microsoft.Extensions.Diagnostics.Probes (1)
TcpEndpointProbesService.cs (1)
87using var client = await _listener.AcceptTcpClientAsync(cancellationToken).ConfigureAwait(false);
Microsoft.Extensions.Http (1)
Logging\HttpClientLoggerHandler.cs (1)
33? await _httpClientAsyncLogger.LogRequestStartAsync(request, cancellationToken).ConfigureAwait(false)
Microsoft.Extensions.Http.Diagnostics (8)
Logging\Internal\HttpRequestBodyReader.cs (2)
76return await ReadFromStreamAsync(request, readSizeLimit, joinedTokenSource.Token).ConfigureAwait(false); 101var charsWritten = await streamToReadFrom.ReadAsync(memory, cancellationToken).ConfigureAwait(false);
Logging\Internal\HttpRequestReader.cs (2)
112.ConfigureAwait(false); 128logRecord.ResponseBody = await _httpResponseBodyReader.ReadAsync(response, cancellationToken).ConfigureAwait(false);
Logging\Internal\HttpResponseBodyReader.cs (4)
81return await ReadFromStreamAsync(response, readSizeLimit, joinedTokenSource.Token).ConfigureAwait(false); 138int bytesRead = await stream.ReadAtLeastAsync(memory, bufferSize, false, cancellationToken).ConfigureAwait(false); 169int bytesRead = await stream.ReadAsync(memory, cancellationToken).ConfigureAwait(false); 177FlushResult result = await writer.FlushAsync(cancellationToken).ConfigureAwait(false);
Microsoft.Extensions.Http.Diagnostics.Tests (1)
Logging\HttpRequestBodyReaderTest.cs (1)
114await httpRequestBodyReader.ReadAsync(httpRequest, token).ConfigureAwait(false);
Microsoft.Extensions.Http.Resilience (5)
Hedging\Internals\RequestMessageSnapshotStrategy.cs (1)
34return await callback(context, state).ConfigureAwait(context.ContinueOnCapturedContext);
Polly\HttpRetryStrategyOptionsExtensions.cs (1)
53var result = await shouldHandle(args).ConfigureAwait(args.Context.ContinueOnCapturedContext);
Resilience\ResilienceHandler.cs (1)
89.ConfigureAwait(context.ContinueOnCapturedContext);
Routing\Internal\RoutingResilienceStrategy.cs (2)
39return await callback(context, state).ConfigureAwait(context.ContinueOnCapturedContext); 55return await callback(context, state).ConfigureAwait(context.ContinueOnCapturedContext);
Microsoft.Extensions.Options.Contextual (1)
Internal\ContextualOptionsFactory.cs (1)
101using var configurer = await loadTasks[i].ConfigureAwait(false); // ValueTasks are awaited only here and only once.
Microsoft.Extensions.Options.Contextual.Tests (1)
AcceptanceTests.cs (1)
57WeatherForecastOptions options = await _contextualOptions.GetAsync(context, cancellationToken).ConfigureAwait(false);
Microsoft.Extensions.ServiceDiscovery (6)
Http\HttpServiceEndpointResolver.cs (2)
50var (valid, endpoint) = await resolver.TryGetEndpointAsync(request, cancellationToken).ConfigureAwait(false); 206await _watcher.GetEndpointsAsync(cancellationToken).ConfigureAwait(false);
Http\ResolvingHttpClientHandler.cs (1)
25var result = await _resolver.GetEndpointAsync(request, cancellationToken).ConfigureAwait(false);
Http\ResolvingHttpDelegatingHandler.cs (1)
46var result = await _resolver.GetEndpointAsync(request, cancellationToken).ConfigureAwait(false);
ServiceEndpointResolver.cs (2)
58var (valid, result) = await resolver.GetEndpointsAsync(cancellationToken).ConfigureAwait(false); 199var endpoints = await _watcher.GetEndpointsAsync(cancellationToken).ConfigureAwait(false);
Microsoft.Extensions.ServiceDiscovery.Dns (13)
DnsServiceEndpointProvider.cs (1)
36var addresses = await resolver.ResolveIPAddressesAsync(hostName, ShutdownToken).ConfigureAwait(false);
DnsSrvServiceEndpointProvider.cs (1)
39var result = await resolver.ResolveServiceAsync(srvQuery, cancellationToken: ShutdownToken).ConfigureAwait(false);
Resolver\DnsResolver.cs (11)
137AddressResult[] ipv4Addresses = await ipv4AddressesTask.ConfigureAwait(false); 138AddressResult[] ipv6Addresses = await ipv6AddressesTask.ConfigureAwait(false); 348(SendQueryError error, TResult[] result) = await SendQueryWithRetriesAsync(name, dnsSafeName, queryType, processResponseFunc, cancellationToken).ConfigureAwait(false); 377SendQueryResult queryResult = await SendQueryToServerWithTimeoutAsync(serverEndPoint, name, dnsSafeName, queryType, attempt, cancellationToken).ConfigureAwait(false); 472return await SendQueryToServerAsync(serverEndPoint, name, dnsSafeName, queryType, attempt, cts.Token).ConfigureAwait(false); 516(responseReader, header) = await SendDnsQueryCoreUdpAsync(serverEndPoint, dnsSafeName, queryType, cancellationToken).ConfigureAwait(false); 523(responseReader, header, sendError) = await SendDnsQueryCoreTcpAsync(serverEndPoint, dnsSafeName, queryType, cancellationToken).ConfigureAwait(false); 727await socket.SendToAsync(memory.Slice(0, length), SocketFlags.None, serverEndPoint, cancellationToken).ConfigureAwait(false); 737int packetLength = await socket.ReceiveAsync(memory, SocketFlags.None, cancellationToken).ConfigureAwait(false); 778await socket.SendAsync(buffer.AsMemory(0, length + 2), SocketFlags.None, cancellationToken).ConfigureAwait(false); 784int read = await socket.ReceiveAsync(buffer.AsMemory(bytesRead), SocketFlags.None, cancellationToken).ConfigureAwait(false);
Microsoft.Extensions.ServiceDiscovery.Tests (1)
ServiceEndpointResolverTests.cs (1)
259await resolveTask.ConfigureAwait(false);
Microsoft.Extensions.ServiceDiscovery.Yarp (1)
ServiceDiscoveryDestinationResolver.cs (1)
60var result = await resolver.GetEndpointsAsync(serviceName, cancellationToken).ConfigureAwait(false);
Microsoft.ML.Data (1)
Transforms\RowShufflingTransformer.cs (1)
571while (await _toProduceChannel.Reader.WaitToReadAsync().ConfigureAwait(false))
Microsoft.ML.Tokenizers (12)
Model\BertTokenizer.cs (1)
702(Dictionary<StringSpanOrdinalKey, int> vocab, Dictionary<int, string> vocabReverse) = await LoadVocabAsync(vocabStream, useAsync: true, cancellationToken).ConfigureAwait(false);
Model\BPETokenizer.cs (3)
273(Dictionary<StringSpanOrdinalKey, int>? vocab, Vec<(string, string)> merges) result = await ReadModelDataAsync(vocabStream, mergesStream, useAsync: true).ConfigureAwait(false); 1102await ConvertMergesToHashmapAsync(merges, useAsync, cancellationToken).ConfigureAwait(false) : 1146await Helpers.ReadLineAsync(reader, cancellationToken).ConfigureAwait(false) :
Model\TiktokenTokenizer.cs (6)
168string? line = useAsync ? await Helpers.ReadLineAsync(reader, cancellationToken).ConfigureAwait(false) : reader.ReadLine(); 179line = useAsync ? await Helpers.ReadLineAsync(reader, cancellationToken).ConfigureAwait(false) : reader.ReadLine(); 189line = useAsync ? await Helpers.ReadLineAsync(reader, cancellationToken).ConfigureAwait(false) : reader.ReadLine(); 203} while ((line = useAsync ? await Helpers.ReadLineAsync(reader, cancellationToken).ConfigureAwait(false) : reader.ReadLine()) is not null); 226await Helpers.ReadLineAsync(reader, cancellationToken).ConfigureAwait(false) : 1331await LoadTiktokenBpeAsync(vocabStream, useAsync: true, cancellationToken).ConfigureAwait(false);
Model\WordPieceTokenizer.cs (2)
103string? line = useAsync ? await Helpers.ReadLineAsync(reader, cancellationToken).ConfigureAwait(false) : reader.ReadLine(); 115line = useAsync ? await Helpers.ReadLineAsync(reader, cancellationToken).ConfigureAwait(false) : reader.ReadLine();
Microsoft.VisualBasic.Forms (1)
Microsoft\VisualBasic\ApplicationServices\SingleInstanceHelpers.vb (1)
27cancellationToken).ConfigureAwait(continueOnCapturedContext:=False)
Microsoft.VisualBasic.Forms.Tests (1)
System\Windows\Forms\SingleInstanceHelpersTests.vb (1)
72.ConfigureAwait(continueOnCapturedContext:=True)
Microsoft.VisualStudio.LanguageServices (45)
CodeLens\CodeLensCallbackListener.cs (4)
75var projectVersion = await service.GetProjectCodeLensVersionAsync(solution, project.Id, cancellationToken).ConfigureAwait(false); 103var currentProjectVersion = await service.GetProjectCodeLensVersionAsync(solution, documentId.ProjectId, cancellationToken).ConfigureAwait(false); 138var projectVersion = await service.GetProjectCodeLensVersionAsync(solution, documentId.ProjectId, cancellationToken).ConfigureAwait(false); 250sourceGeneratorDocumentId, includeSourceGenerated: true, cancellationToken).ConfigureAwait(false);
CodeLens\RemoteCodeLensReferencesService.cs (1)
146var document = await solution.GetDocumentAsync(referencedDocumentId, includeSourceGenerated: true, cancellationToken).ConfigureAwait(false);
FindReferences\Contexts\AbstractTableDataSourceFindUsagesContext.cs (1)
440var sourceText = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
KeybindingReset\KeybindingResetDetector.cs (1)
188currentStatus = await IsReSharperRunningAsync(cancellationToken).ConfigureAwait(false);
LanguageClient\VisualStudioLogHubLoggerFactory.cs (2)
48var configuration = await TraceConfiguration.CreateTraceConfigurationInstanceAsync(service, ownsServiceBroker: true, cancellationToken).ConfigureAwait(false); 56var traceSource = await configuration.RegisterLogSourceAsync(logId, logOptions, cancellationToken).ConfigureAwait(false);
LanguageService\AbstractLanguageService`2.VsLanguageDebugInfo.cs (1)
220var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Packaging\PackageInstallerServiceFactory.cs (3)
232var packageSourceProvider = await GetPackageSourceProviderAsync().ConfigureAwait(false); 507var nugetService = await serviceBroker.GetProxyAsync<INuGetProjectService>(NuGetServices.NuGetProjectServiceV1, cancellationToken: cancellationToken).ConfigureAwait(false); 516return await doWorkAsync(nugetService, cancellationToken).ConfigureAwait(false);
ProjectSystem\BrokeredService\WorkspaceProject.cs (15)
34var disposableBatchScope = await _project.CreateBatchScopeAsync(cancellationToken).ConfigureAwait(false); 43var disposableBatchScope = await _project.CreateBatchScopeAsync(cancellationToken).ConfigureAwait(false); 52var disposableBatchScope = await _project.CreateBatchScopeAsync(cancellationToken).ConfigureAwait(false); 61var disposableBatchScope = await _project.CreateBatchScopeAsync(cancellationToken).ConfigureAwait(false); 69var disposableBatchScope = await _project.CreateBatchScopeAsync(cancellationToken).ConfigureAwait(false); 78var disposableBatchScope = await _project.CreateBatchScopeAsync(cancellationToken).ConfigureAwait(false); 87var disposableBatchScope = await _project.CreateBatchScopeAsync(cancellationToken).ConfigureAwait(false); 96var disposableBatchScope = await _project.CreateBatchScopeAsync(cancellationToken).ConfigureAwait(false); 109var disposableBatchScope = await _project.CreateBatchScopeAsync(cancellationToken).ConfigureAwait(false); 120var disposableBatchScope = await _project.CreateBatchScopeAsync(cancellationToken).ConfigureAwait(false); 132var disposableBatchScope = await _project.CreateBatchScopeAsync(cancellationToken).ConfigureAwait(false); 141var disposableBatchScope = await _project.CreateBatchScopeAsync(cancellationToken).ConfigureAwait(false); 150var disposableBatchScope = await _project.CreateBatchScopeAsync(cancellationToken).ConfigureAwait(false); 159var disposableBatchScope = await _project.CreateBatchScopeAsync(cancellationToken).ConfigureAwait(false); 186var disposableBatchScope = await _project.CreateBatchScopeAsync(cancellationToken).ConfigureAwait(false);
ProjectSystem\VisualStudioProjectFactory.cs (1)
125await ((IVsTypeScriptVisualStudioProjectFactory)this).CreateAndAddToWorkspaceAsync(projectSystemName, language, projectFilePath, hierarchy, projectGuid, CancellationToken.None).ConfigureAwait(false));
StackTraceExplorer\StackFrameViewModel.cs (1)
112var sourceText = await textDocument.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
TableDataSource\Suppression\VisualStudioDiagnosticListSuppressionStateService.cs (1)
264var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
TaskList\ExternalErrorDiagnosticUpdateSource.cs (1)
266cancellationToken: cancellationToken).ConfigureAwait(false);
ValueTracking\ValueTrackingCommandHandler.cs (5)
136solution, child, children: [], toolWindow.ViewModel, _glyphService, valueTrackingService, _globalOptions, _threadingContext, _listener, _threadOperationExecutor, cancellationToken).ConfigureAwait(false); 146solution, child, children: [], toolWindow.ViewModel, _glyphService, valueTrackingService, _globalOptions, _threadingContext, _listener, _threadOperationExecutor, cancellationToken).ConfigureAwait(false); 151solution, parent, childItems.ToImmutable(), toolWindow.ViewModel, _glyphService, valueTrackingService, _globalOptions, _threadingContext, _listener, _threadOperationExecutor, cancellationToken).ConfigureAwait(false); 169var roslynPackage = await RoslynPackage.GetOrLoadAsync(_threadingContext, _serviceProvider, cancellationToken).ConfigureAwait(false); 181var roslynPackage = await RoslynPackage.GetOrLoadAsync(_threadingContext, _serviceProvider, cancellationToken).ConfigureAwait(false);
Venus\ContainedDocument.DocumentServiceProvider.cs (2)
89var sourceText = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 138var sourceText = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Workspace\SourceGeneratedFileManager.cs (2)
349generatedDocument = await project.GetSourceGeneratedDocumentAsync(_documentIdentity.DocumentId, cancellationToken).ConfigureAwait(false); 356generatedSource = await generatedDocument.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Workspace\VisualStudioDocumentNavigationService.cs (2)
128var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 191var textDocument = await solution.GetTextDocumentAsync(documentId, cancellationToken).ConfigureAwait(false);
Workspace\VisualStudioWorkspaceStatusServiceFactory.cs (2)
113var status = await GetProgressStageStatusAsync(cancellationToken).ConfigureAwait(false); 133var status = await GetProgressStageStatusAsync(cancellationToken).ConfigureAwait(false);
Microsoft.VisualStudio.LanguageServices.DevKit (4)
SourceLink\VSCodeSourceLinkService.cs (2)
28var proxy = await _serviceBroker.GetProxyAsync<IDebuggerSymbolLocatorService>(BrokeredServiceDescriptors.DebuggerSymbolLocatorService, cancellationToken).ConfigureAwait(false); 52var proxy = await _serviceBroker.GetProxyAsync<IDebuggerSourceLinkService>(BrokeredServiceDescriptors.DebuggerSourceLinkService, cancellationToken).ConfigureAwait(false);
src\EditorFeatures\Core\EditAndContinue\Contracts\ManagedHotReloadServiceBridge.cs (2)
17=> (await service.GetActiveStatementsAsync(cancellation).ConfigureAwait(false)).SelectAsArray(a => a.ToContract()); 20=> (await service.GetAvailabilityAsync(module, cancellation).ConfigureAwait(false)).ToContract();
Microsoft.VisualStudio.LanguageServices.LiveShare (1)
Client\RemoteLanguageServiceWorkspace.cs (1)
296var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Microsoft.VisualStudio.LanguageServices.Xaml (9)
Implementation\LanguageServer\Handler\Completion\CompletionHandler.cs (1)
66var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Implementation\LanguageServer\Handler\Definitions\GoToDefinitionHandler.cs (1)
118var document = await solution.GetTextDocumentAsync(new TextDocumentIdentifier { DocumentUri = ProtocolConversions.CreateAbsoluteDocumentUri(sourceDefinition.FilePath) }, cancellationToken).ConfigureAwait(false);
Implementation\LanguageServer\Handler\Diagnostics\AbstractPullDiagnosticHandler.cs (1)
97var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Implementation\LanguageServer\Handler\FoldingRanges\FoldingRangesHandler.cs (1)
54var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Implementation\LanguageServer\Handler\Formatting\AbstractFormatDocumentHandlerBase.cs (1)
35var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Implementation\LanguageServer\Handler\Formatting\FormatDocumentOnTypeHandler.cs (1)
51var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Implementation\LanguageServer\Handler\Hover\HoverHandler.cs (1)
81var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Implementation\LanguageServer\Handler\OnAutoInsert\OnAutoInsertHandler.cs (1)
47var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Implementation\LanguageServer\Handler\OnTypeRename\OnTypeRenameHandler.cs (1)
79var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Roslyn.Diagnostics.Analyzers (60)
src\Dependencies\Collections\Extensions\IEnumerableExtensions.cs (4)
483builder.Add(await selector(item).ConfigureAwait(false)); 498builder.Add(await selector(item, cancellationToken).ConfigureAwait(false)); 513builder.Add(await selector(item, arg, cancellationToken).ConfigureAwait(false)); 525builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
src\Dependencies\Collections\Extensions\ImmutableArrayExtensions.cs (3)
427builder[i] = await selector(array[i], cancellationToken).ConfigureAwait(false); 445builder[i] = await selector(array[i], arg, cancellationToken).ConfigureAwait(false); 471builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
src\Dependencies\Threading\AsyncBatchingWorkQueue`2.cs (1)
220return (ranToCompletion: true, await ProcessNextBatchAsync().ConfigureAwait(false));
src\Dependencies\Threading\ValueTaskExtensions.cs (2)
237_task.ConfigureAwait(_captureContext).GetAwaiter().OnCompleted(continuation); 247_task.ConfigureAwait(_captureContext).GetAwaiter().UnsafeOnCompleted(continuation);
src\RoslynAnalyzers\Utilities\Refactoring\CodeRefactoringContextExtensions.cs (1)
44var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Utilities\IAsyncEnumerableExtensions.cs (1)
84while (await reader.WaitToReadAsync(cancellationToken).ConfigureAwait(false))
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Utilities\ProducerConsumer.cs (1)
47while (await reader.WaitToReadAsync(cancellationToken).ConfigureAwait(false))
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\AddImport\AddImportPlacementOptionsProviders.cs (1)
29var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeCleanup\CodeCleanupOptionsProviders.cs (1)
29var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeFixes\ForkingSyntaxEditorBasedCodeFixProvider.cs (1)
99changedRoot, cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeFixes\SyntaxEditorBasedCodeFixProvider.cs (1)
83var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeGeneration\AbstractCodeGenerationService.cs (2)
244var codeGenOptions = await oldDocument.GetCodeGenerationOptionsAsync(cancellationToken).ConfigureAwait(false); 256var addImportsOptions = await newDocument.GetAddImportPlacementOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeGeneration\CleanCodeGenerationOptions.cs (2)
42GenerationOptions = await document.GetCodeGenerationOptionsAsync(cancellationToken).ConfigureAwait(false), 43CleanupOptions = await document.GetCodeCleanupOptionsAsync(cancellationToken).ConfigureAwait(false)
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeGeneration\CodeGenerationOptionsProviders.cs (2)
36var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false); 44var options = await GetCodeGenerationOptionsAsync(document, cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeRefactorings\CodeRefactoringContextExtensions.cs (4)
46var parsedDocument = await ParsedDocument.CreateAsync(context.Document, context.CancellationToken).ConfigureAwait(false); 55var parsedDocument = await ParsedDocument.CreateAsync(context.Document, context.CancellationToken).ConfigureAwait(false); 61var parsedDocument = await ParsedDocument.CreateAsync(document, cancellationToken).ConfigureAwait(false); 84var parsedDocument = await ParsedDocument.CreateAsync(document, cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Editing\ImportAdderService.cs (5)
37var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 120var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 121var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 180var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 183var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Extensions\DocumentExtensions.cs (3)
132var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 136return await ReuseExistingSpeculativeModelAsync(document, node, cancellationToken).ConfigureAwait(false); 225var syntaxTree = await document.GetRequiredSyntaxTreeAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Formatting\DocumentFormattingOptionsProviders.cs (1)
24var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Formatting\LineFormattingOptionsProviders.cs (1)
19var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Formatting\SyntaxFormattingOptionsProviders.cs (1)
22var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\LanguageServices\InitializeParameter\AbstractInitializerParameterService.cs (2)
119var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 123var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\LanguageServices\RemoveUnnecessaryImports\AbstractRemoveUnnecessaryImportsService.cs (2)
27var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 34var currentModel = await current.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\NamingStyles\NamingStylePreferencesProviders.cs (1)
17var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Options\MemberDisplayOptions.cs (1)
52var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\SemanticModelReuse\SemanticModelWorkspaceServiceFactory.SemanticModelWorkspaceService.cs (2)
104return await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 159var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Simplification\AbstractSimplificationService.cs (6)
69var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 96var root = (TCompilationUnitSyntax)await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 107root = (TCompilationUnitSyntax)await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 165var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 236semanticModelForReduce = await newDocument.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 291var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Simplification\SimplifierOptionsProviders.cs (1)
22var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Utilities\ParsedDocument.cs (2)
33var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 34var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Utilities\SemanticDocument.cs (3)
20var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 21var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 22var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Utilities\SyntacticDocument.cs (2)
30var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 31var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
Roslyn.VisualStudio.DiagnosticsWindow (1)
Panels\WorkspacePanel.xaml.cs (1)
91var snapshotText = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false);
Roslyn.VisualStudio.Next.UnitTests (2)
Remote\SerializationValidator.cs (2)
32var value = await GetAssetAsync<T>(assetPath, checksum, cancellationToken).ConfigureAwait(false); 85var data = await AssetStorage.GetTestAccessor().GetRequiredAssetAsync(checksum, CancellationToken.None).ConfigureAwait(false);
Shared (3)
ServerSentEvents\SseParser_1.cs (3)
205while (await FillLineBufferAsync(cancellationToken).ConfigureAwait(false) != 0 && _lineLength < Utf8Bom.Length) ; 255_ = await FillLineBufferAsync(cancellationToken).ConfigureAwait(false); 527.ConfigureAwait(false);
System.Diagnostics.Process (1)
System\Diagnostics\AsyncStreamReader.cs (1)
97int bytesRead = await _stream.ReadAsync(new Memory<byte>(_byteBuffer), _cts.Token).ConfigureAwait(false);
System.Formats.Tar (12)
System\Formats\Tar\SubReadStream.cs (1)
166int ret = await _superStream.ReadAsync(buffer, cancellationToken).ConfigureAwait(false);
System\Formats\Tar\TarFile.cs (1)
508while ((entry = await reader.GetNextEntryAsync(cancellationToken: cancellationToken).ConfigureAwait(false)) != null)
System\Formats\Tar\TarHeader.Read.cs (2)
278_dataStream = await GetDataStreamAsync(archiveStream, copyData, _size, cancellationToken).ConfigureAwait(false); 297await TarHelpers.SkipBlockAlignmentPaddingAsync(archiveStream, _size, cancellationToken).ConfigureAwait(false);
System\Formats\Tar\TarReader.cs (8)
277await TarHelpers.SkipBlockAlignmentPaddingAsync(_archiveStream, _previouslyReadEntry._header._size, cancellationToken).ConfigureAwait(false); 286TarHeader? header = await TryGetNextEntryHeaderAsync(copyData, cancellationToken).ConfigureAwait(false); 363TarHeader? header = await TarHeader.TryGetNextHeaderAsync(_archiveStream, copyData, TarEntryFormat.Unknown, processDataBlock: true, cancellationToken).ConfigureAwait(false); 374TarHeader? mainHeader = await TryProcessExtendedAttributesHeaderAsync(header, copyData, cancellationToken).ConfigureAwait(false); 384TarHeader? mainHeader = await TryProcessGnuMetadataHeaderAsync(header, copyData, cancellationToken).ConfigureAwait(false); 434TarHeader? actualHeader = await TarHeader.TryGetNextHeaderAsync(_archiveStream, copyData, TarEntryFormat.Pax, processDataBlock: false, cancellationToken).ConfigureAwait(false); 547TarHeader? secondHeader = await TarHeader.TryGetNextHeaderAsync(_archiveStream, copyData, TarEntryFormat.Gnu, processDataBlock: true, cancellationToken).ConfigureAwait(false); 566TarHeader? thirdHeader = await TarHeader.TryGetNextHeaderAsync(_archiveStream, copyData, TarEntryFormat.Gnu, processDataBlock: true, cancellationToken).ConfigureAwait(false);
System.IO.Compression (11)
System\IO\Compression\DeflateManaged\DeflateManagedStream.cs (1)
209int bytesRead = await readTask.ConfigureAwait(false);
System\IO\Compression\DeflateZLib\DeflateStream.cs (1)
459int n = await _stream.ReadAsync(new Memory<byte>(_buffer, 0, _buffer.Length), cancellationToken).ConfigureAwait(false);
System\IO\Compression\ZipArchive.Async.cs (1)
201int currBytesRead = await _archiveStream.ReadAtLeastAsync(fileBuffer, ZipCentralDirectoryFileHeader.BlockConstantSectionSize, throwOnEndOfStream: false, cancellationToken).ConfigureAwait(false);
System\IO\Compression\ZipBlocks.Async.cs (6)
63int bytesRead = await stream.ReadAtLeastAsync(blockContents, blockContents.Length, throwOnEndOfStream: false, cancellationToken).ConfigureAwait(false); 88int bytesRead = await stream.ReadAtLeastAsync(blockContents, blockContents.Length, throwOnEndOfStream: false, cancellationToken).ConfigureAwait(false); 151int bytesRead = await stream.ReadAtLeastAsync(blockBytes, blockBytes.Length, throwOnEndOfStream: false, cancellationToken).ConfigureAwait(false); 156bytesRead = await stream.ReadAtLeastAsync(blockBytes, blockBytes.Length, throwOnEndOfStream: false, cancellationToken).ConfigureAwait(false); 203int realBytesRead = await furtherReads.ReadAtLeastAsync(collatedHeader.AsMemory(remainingBufferLength..), bytesToRead, throwOnEndOfStream: false, cancellationToken).ConfigureAwait(false); 248int bytesRead = await stream.ReadAtLeastAsync(blockContents, blockContents.Length, throwOnEndOfStream: false, cancellationToken).ConfigureAwait(false);
System\IO\Compression\ZipCustomStreams.cs (1)
359int ret = await _superStream.ReadAsync(buffer, cancellationToken).ConfigureAwait(false);
System\IO\Compression\ZipHelper.Async.cs (1)
20int bytesRead = await stream.ReadAtLeastAsync(buffer, bytesToRead, throwOnEndOfStream: false, cancellationToken).ConfigureAwait(false);
System.IO.Compression.Brotli (1)
System\IO\Compression\dec\BrotliStream.Decompress.cs (1)
154int bytesRead = await _stream.ReadAsync(_buffer.AsMemory(_bufferCount), cancellationToken).ConfigureAwait(false);
System.IO.Pipelines (11)
System\IO\Pipelines\PipeReader.cs (3)
70ReadResult result = await ReadAsync(cancellationToken).ConfigureAwait(false); 236ReadResult result = await ReadAsync(cancellationToken).ConfigureAwait(false); 258FlushResult flushResult = await writeAsync(destination, memory, cancellationToken).ConfigureAwait(false);
System\IO\Pipelines\PipeReaderStream.cs (1)
107ReadResult result = await _pipeReader.ReadAsync(cancellationToken).ConfigureAwait(false);
System\IO\Pipelines\PipeWriter.cs (2)
128int read = await source.ReadAsync(buffer, cancellationToken).ConfigureAwait(false); 137FlushResult result = await FlushAsync(cancellationToken).ConfigureAwait(false);
System\IO\Pipelines\PipeWriterStream.cs (1)
115FlushResult result = await valueTask.ConfigureAwait(false);
System\IO\Pipelines\StreamPipeReader.cs (3)
262await reader.InnerStream.ReadAsync(Memory<byte>.Empty, tokenSource.Token).ConfigureAwait(false); 271int length = await reader.InnerStream.ReadAsync(buffer, tokenSource.Token).ConfigureAwait(false); 339FlushResult flushResult = await destination.WriteAsync(segment.Memory.Slice(segmentIndex), tokenSource.Token).ConfigureAwait(false);
System\IO\Pipelines\StreamPipeWriter.cs (1)
248await FlushAsyncInternal(writeToStream: exception == null, data: Memory<byte>.Empty).ConfigureAwait(false);
System.IO.Pipes (3)
System\IO\Pipes\NamedPipeServerStream.Unix.cs (1)
86acceptedSocket = await _instance!.ListeningSocket.AcceptAsync(linkedTokenSource.Token).ConfigureAwait(false);
System\IO\Pipes\PipeStream.Unix.cs (2)
307return await InternalHandle!.PipeSocket.ReceiveAsync(destination, SocketFlags.None, cancellationToken).ConfigureAwait(false); 321int bytesWritten = await _handle!.PipeSocket.SendAsync(source, SocketFlags.None, cancellationToken).ConfigureAwait(false);
System.Net.Http (92)
System\Net\Http\MultipartContent.cs (1)
546int bytesRead = await _current.ReadAsync(buffer, cancellationToken).ConfigureAwait(false);
System\Net\Http\SocketsHttpHandler\AuthenticationHelper.cs (6)
241HttpResponseMessage response = await InnerSendAsync(request, async, isProxyAuth, doRequestAuth, pool, cancellationToken).ConfigureAwait(false); 255if (await TrySetDigestAuthToken(request, challenge.Credential, digestResponse, isProxyAuth).ConfigureAwait(false)) 258response = await InnerSendAsync(request, async, isProxyAuth, doRequestAuth, pool, cancellationToken).ConfigureAwait(false); 265await TrySetDigestAuthToken(request, challenge.Credential, digestResponse, isProxyAuth).ConfigureAwait(false)) 268response = await InnerSendAsync(request, async, isProxyAuth, doRequestAuth, pool, cancellationToken).ConfigureAwait(false); 300response = await InnerSendAsync(request, async, isProxyAuth, doRequestAuth, pool, cancellationToken).ConfigureAwait(false);
System\Net\Http\SocketsHttpHandler\AuthenticationHelper.NtAuth.cs (1)
106connection = await connectionPool.CreateHttp11ConnectionAsync(request, async, cancellationToken).ConfigureAwait(false);
System\Net\Http\SocketsHttpHandler\ChunkedEncodingReadStream.cs (2)
189int bytesRead = await _connection.ReadAsync(buffer.Slice(0, (int)Math.Min((ulong)buffer.Length, _chunkBytesRemaining))).ConfigureAwait(false); 209await _connection.ReadAsync(buffer).ConfigureAwait(false);
System\Net\Http\SocketsHttpHandler\ConnectHelper.cs (1)
131}, cancellationToken).ConfigureAwait(false);
System\Net\Http\SocketsHttpHandler\ConnectionCloseReadStream.cs (1)
60bytesRead = await readTask.ConfigureAwait(false);
System\Net\Http\SocketsHttpHandler\ConnectionPool\HttpConnectionPool.cs (15)
419response = await TrySendUsingHttp3Async(request, cancellationToken).ConfigureAwait(false); 444connection = await http2ConnectionWaiter.WaitForConnectionAsync(request, this, async, cancellationToken).ConfigureAwait(false); 452await connection.InitialSettingsReceived.WaitWithCancellationAsync(cancellationToken).ConfigureAwait(false); 476connection = await http11ConnectionWaiter.WaitForConnectionAsync(request, this, async, cancellationToken).ConfigureAwait(false); 569stream = await ConnectToTcpHostAsync(_originAuthority.IdnHost, _originAuthority.Port, request, async, cancellationToken).ConfigureAwait(false); 574stream = await ConnectHelper.EstablishSslConnectionAsync(_sslOptionsProxy, request, async, stream, cancellationToken).ConfigureAwait(false); 579stream = await ConnectToTcpHostAsync(_proxyUri!.IdnHost, _proxyUri.Port, request, async, cancellationToken).ConfigureAwait(false); 584stream = await ConnectHelper.EstablishSslConnectionAsync(_sslOptionsProxy, request, async, stream, cancellationToken).ConfigureAwait(false); 590stream = await EstablishProxyTunnelAsync(async, cancellationToken).ConfigureAwait(false); 601stream = await EstablishSocksTunnel(request, async, cancellationToken).ConfigureAwait(false); 614sslStream = await ConnectHelper.EstablishSslConnectionAsync(GetSslOptionsForRequest(request), request, async, stream, cancellationToken).ConfigureAwait(false); 667stream = await streamTask.ConfigureAwait(false) ?? throw new HttpRequestException(SR.net_http_null_from_connect_callback); 744newStream = await streamTask.ConfigureAwait(false); 777HttpResponseMessage tunnelResponse = await _poolManager.SendProxyConnectAsync(tunnelRequest, _proxyUri!, async, cancellationToken).ConfigureAwait(false); 800Stream stream = await ConnectToTcpHostAsync(_proxyUri.IdnHost, _proxyUri.Port, request, async, cancellationToken).ConfigureAwait(false);
System\Net\Http\SocketsHttpHandler\ConnectionPool\HttpConnectionPool.Http1.cs (4)
265connection = await CreateHttp11ConnectionAsync(queueItem.Request, true, cts.Token).ConfigureAwait(false); 296(Stream stream, TransportContext? transportContext, Activity? activity, IPEndPoint? remoteEndPoint) = await ConnectAsync(request, async, cancellationToken).ConfigureAwait(false); 297return await ConstructHttp11ConnectionAsync(async, stream, transportContext, request, activity, remoteEndPoint, cancellationToken).ConfigureAwait(false); 302Stream newStream = await ApplyPlaintextFilterAsync(async, stream, HttpVersion.Version11, request, cancellationToken).ConfigureAwait(false);
System\Net\Http\SocketsHttpHandler\ConnectionPool\HttpConnectionPool.Http2.cs (5)
187(Stream stream, TransportContext? transportContext, Activity? activity, IPEndPoint? remoteEndPoint) = await ConnectAsync(queueItem.Request, true, cts.Token).ConfigureAwait(false); 204connection = await ConstructHttp2ConnectionAsync(stream, queueItem.Request, activity, remoteEndPoint, cts.Token).ConfigureAwait(false); 216connection = await ConstructHttp2ConnectionAsync(stream, queueItem.Request, activity, remoteEndPoint, cts.Token).ConfigureAwait(false); 248stream = await ApplyPlaintextFilterAsync(async: true, stream, HttpVersion.Version20, request, cancellationToken).ConfigureAwait(false); 347http11Connection = await ConstructHttp11ConnectionAsync(true, stream, transportContext, request, activity, remoteEndPoint, cancellationToken).ConfigureAwait(false);
System\Net\Http\SocketsHttpHandler\ConnectionPool\HttpConnectionPool.Http3.cs (2)
96connection = await http3ConnectionWaiter.WaitWithCancellationAsync(cancellationToken).ConfigureAwait(false); 274QuicConnection quicConnection = await ConnectHelper.ConnectQuicAsync(queueItem.Request, new DnsEndPoint(authority.IdnHost, authority.Port), _poolManager.Settings._pooledConnectionIdleTimeout, _sslOptionsHttp3!, connection.StreamCapacityCallback, cts.Token).ConfigureAwait(false);
System\Net\Http\SocketsHttpHandler\ConnectionPool\HttpConnectionWaiter.cs (1)
40return await WaitWithCancellationAsync(async, requestCancellationToken).ConfigureAwait(false);
System\Net\Http\SocketsHttpHandler\ContentLengthReadStream.cs (1)
85bytesRead = await readTask.ConfigureAwait(false);
System\Net\Http\SocketsHttpHandler\DecompressionHandler.cs (5)
69HttpResponseMessage response = await _innerHandler.SendAsync(request, async, cancellationToken).ConfigureAwait(false); 280int firstByte = await thisRef._stream.PeekFirstByteAsync(cancellationToken).ConfigureAwait(false); 282return await thisRef._decompressionStream.ReadAsync(buffer, cancellationToken).ConfigureAwait(false); 297int firstByte = await _stream.PeekFirstByteAsync(cancellationToken).ConfigureAwait(false); 353int bytesRead = await _stream.ReadAsync(buffer, cancellationToken).ConfigureAwait(false);
System\Net\Http\SocketsHttpHandler\Http2Connection.cs (12)
413await _stream.ReadAsync(Memory<byte>.Empty).ConfigureAwait(false); 417int bytesRead = await _stream.ReadAsync(_incomingBuffer.AvailableMemory).ConfigureAwait(false); 460await _stream.ReadAsync(Memory<byte>.Empty).ConfigureAwait(false); 462int bytesRead = await _stream.ReadAsync(_incomingBuffer.AvailableMemory).ConfigureAwait(false); 487frameHeader = await ReadFrameAsync(initialFrame: true).ConfigureAwait(false); 540await zeroByteReadTask.ConfigureAwait(false); 546int bytesRead = await _stream.ReadAsync(_incomingBuffer.AvailableMemory).ConfigureAwait(false); 559frameHeader = await ReadFrameAsync().ConfigureAwait(false); 677frameHeader = await ReadFrameAsync().ConfigureAwait(false); 1210while (await _writeChannel.Reader.WaitToReadAsync().ConfigureAwait(false)) 1719frameSize = await _connectionWindow.RequestCreditAsync(frameSize, cancellationToken).ConfigureAwait(false); 2007Http2Stream http2Stream = await SendHeadersAsync(request, cancellationToken, mustFlush: shouldExpectContinue || request.IsExtendedConnectRequest).ConfigureAwait(false);
System\Net\Http\SocketsHttpHandler\Http2Stream.cs (2)
205sendRequestContent = await WaitFor100ContinueAsync(_requestBodyCancellationSource.Token).ConfigureAwait(false); 1312sendSize = await _creditWaiter.AsValueTask().ConfigureAwait(false);
System\Net\Http\SocketsHttpHandler\Http3Connection.cs (11)
284quicStream = await conn.OpenOutboundStreamAsync(QuicStreamType.Bidirectional, cancellationToken).ConfigureAwait(false); 488_clientControl = await _connection!.OpenOutboundStreamAsync(QuicStreamType.Unidirectional).ConfigureAwait(false); 552QuicStream stream = await streamTask.ConfigureAwait(false); 598bytesRead = await stream.ReadAsync(buffer.AvailableMemory, CancellationToken.None).ConfigureAwait(false); 674bytesRead = await stream.ReadAsync(buffer.AvailableMemory, CancellationToken.None).ConfigureAwait(false); 726(Http3FrameType? frameType, long payloadLength) = await ReadFrameEnvelopeAsync().ConfigureAwait(false); 745(frameType, payloadLength) = await ReadFrameEnvelopeAsync().ConfigureAwait(false); 808bytesRead = await stream.ReadAsync(buffer.AvailableMemory, CancellationToken.None).ConfigureAwait(false); 841bytesRead = await stream.ReadAsync(buffer.AvailableMemory, CancellationToken.None).ConfigureAwait(false); 892bytesRead = await stream.ReadAsync(buffer.AvailableMemory, CancellationToken.None).ConfigureAwait(false); 921int bytesRead = await stream.ReadAsync(buffer.AvailableMemory, CancellationToken.None).ConfigureAwait(false);
System\Net\Http\SocketsHttpHandler\Http3RequestStream.cs (8)
397(Http3FrameType? frameType, long payloadLength) = await ReadFrameEnvelopeAsync(cancellationToken).ConfigureAwait(false); 564(frameType, payloadLength) = await ReadFrameEnvelopeAsync(cancellationToken).ConfigureAwait(false); 864bytesRead = await _stream.ReadAsync(_recvBuffer.AvailableMemory, cancellationToken).ConfigureAwait(false); 933int bytesRead = await _stream.ReadAsync(_recvBuffer.AvailableMemory, cancellationToken).ConfigureAwait(false); 1132int bytesRead = await _stream.ReadAsync(_recvBuffer.AvailableMemory, cancellationToken).ConfigureAwait(false); 1236if (_responseDataPayloadRemaining <= 0 && !await ReadNextDataFrameAsync(response, cancellationToken).ConfigureAwait(false)) 1269int bytesRead = await _stream.ReadAsync(buffer.Slice(0, copyLen), cancellationToken).ConfigureAwait(false); 1357(frameType, payloadLength) = await ReadFrameEnvelopeAsync(cancellationToken).ConfigureAwait(false);
System\Net\Http\SocketsHttpHandler\HttpConnection.cs (8)
255await _stream.ReadAsync(Memory<byte>.Empty).ConfigureAwait(false); 258int read = await _stream.ReadAsync(_readBuffer.AvailableMemory).ConfigureAwait(false); 635bytesRead = await vt.ConfigureAwait(false); 1631await _stream.ReadAsync(_readBuffer.AvailableMemory).ConfigureAwait(false) : 1647await _stream.ReadAsync(_readBuffer.AvailableMemory).ConfigureAwait(false) : 1795int count = await _stream.ReadAsync(destination).ConfigureAwait(false); 1849int bytesRead = await _stream.ReadAsync(_readBuffer.AvailableMemory).ConfigureAwait(false); 2093if (!await responseStream.DrainAsync(_pool.Settings._maxResponseDrainSize).ConfigureAwait(false) ||
System\Net\Http\SocketsHttpHandler\HttpConnectionPoolManager.cs (1)
438return await SendAsyncCore(request, firstProxy, async, doRequestAuth, isProxyConnect: false, cancellationToken).ConfigureAwait(false);
System\Net\Http\SocketsHttpHandler\HttpContentReadStream.cs (1)
78bool drained = await DrainAsync(connection._pool.Settings._maxResponseDrainSize).ConfigureAwait(false);
System\Net\Http\SocketsHttpHandler\RawConnectionStream.cs (1)
67bytesRead = await readTask.ConfigureAwait(false);
System\Net\Http\SocketsHttpHandler\RedirectHandler.cs (2)
29HttpResponseMessage response = await _innerHandler.SendAsync(request, async, cancellationToken).ConfigureAwait(false); 87response = await _innerHandler.SendAsync(request, async, cancellationToken).ConfigureAwait(false);
System\Net\Http\SocketsHttpHandler\SocksHelper.cs (1)
357? await stream.ReadAtLeastAsync(buffer, buffer.Length, throwOnEndOfStream: false).ConfigureAwait(false)
System.Net.Http.Json (14)
System\Net\Http\Json\HttpClientJsonExtensions.cs (3)
89.ConfigureAwait(false); 91return await deserializeMethod(readStream, jsonOptions, linkedCTS?.Token ?? cancellationToken).ConfigureAwait(false); 137Stream contentStream = await task.ConfigureAwait(false);
System\Net\Http\Json\HttpClientJsonExtensions.Get.AsyncEnumerable.cs (1)
164.ConfigureAwait(false);
System\Net\Http\Json\HttpContentJsonExtensions.AsyncEnumerable.cs (1)
99.ConfigureAwait(false);
System\Net\Http\Json\HttpContentJsonExtensions.cs (8)
86using (Stream contentStream = await GetContentStreamAsync(content, cancellationToken).ConfigureAwait(false)) 88return await JsonSerializer.DeserializeAsync(contentStream, type, options ?? JsonSerializerOptions.Web, cancellationToken).ConfigureAwait(false); 96using (Stream contentStream = await GetContentStreamAsync(content, cancellationToken).ConfigureAwait(false)) 98return await JsonSerializer.DeserializeAsync<T>(contentStream, options ?? JsonSerializerOptions.Web, cancellationToken).ConfigureAwait(false); 118using (Stream contentStream = await GetContentStreamAsync(content, cancellationToken).ConfigureAwait(false)) 120return await JsonSerializer.DeserializeAsync(contentStream, type, context, cancellationToken).ConfigureAwait(false); 126using (Stream contentStream = await GetContentStreamAsync(content, cancellationToken).ConfigureAwait(false)) 128return await JsonSerializer.DeserializeAsync(contentStream, jsonTypeInfo, cancellationToken).ConfigureAwait(false);
System\Net\Http\Json\LengthLimitReadStream.cs (1)
64int read = await readTask.ConfigureAwait(false);
System.Net.Mail (4)
System\Net\Base64Stream.cs (1)
202int read = await BaseStream.ReadAsync(buffer, cancellationToken).ConfigureAwait(false);
System\Net\BufferedReadStream.cs (1)
72int returnValue = await BaseStream.ReadAsync(buffer, cancellationToken).ConfigureAwait(false);
System\Net\Mail\SmtpReplyReaderFactory.cs (1)
281read = await TIOAdapter.ReadAsync(_bufferedStream, _byteBuffer, cancellationToken).ConfigureAwait(false);
System\Net\Mime\MimePart.cs (1)
178while ((read = await TIOAdapter.ReadAsync(Stream, buffer.AsMemory(0, maxBufferSize), cancellationToken).ConfigureAwait(false)) > 0)
System.Net.Ping (3)
System\Net\NetworkInformation\Ping.cs (1)
719IPAddress address = await getAddress(getAddressArg, _timeoutOrCancellationSource.Token).ConfigureAwait(false);
System\Net\NetworkInformation\Ping.RawSocket.cs (2)
337.ConfigureAwait(false); 352.ConfigureAwait(false);
System.Net.Quic (3)
System\Net\Quic\QuicConnection.cs (1)
574return await _acceptQueue.Reader.ReadAsync(cancellationToken).ConfigureAwait(false);
System\Net\Quic\QuicListener.cs (2)
183object item = await _acceptQueue.Reader.ReadAsync(cancellationToken).ConfigureAwait(false); 236QuicServerConnectionOptions options = await _connectionOptionsCallback(connection, clientHello, cancellationToken).ConfigureAwait(false);
System.Net.Requests (1)
System\Net\HttpWebResponse.cs (1)
416.ConfigureAwait(false);
System.Net.Security (13)
System\Net\Security\NegotiateStream.cs (4)
366int readBytes = await ReadAllAsync(InnerStream, _readHeader, allowZeroRead: true, cancellationToken).ConfigureAwait(false); 391readBytes = await ReadAllAsync(InnerStream, new Memory<byte>(_readBuffer, 0, readBytes), allowZeroRead: false, cancellationToken).ConfigureAwait(false); 450stream, buffer, buffer.Length, throwOnEndOfStream: false, cancellationToken).ConfigureAwait(false); 864byte[]? message = await _framer.ReadMessageAsync<TIOAdapter>(InnerStream, cancellationToken).ConfigureAwait(false);
System\Net\Security\SslStream.IO.cs (7)
249int frameSize = await ReceiveHandshakeFrameAsync<TIOAdapter>(cancellationToken).ConfigureAwait(false); 333int frameSize = await ReceiveHandshakeFrameAsync<TIOAdapter>(cancellationToken).ConfigureAwait(false); 412int frameSize = await EnsureFullTlsFrameAsync<TIOAdapter>(cancellationToken, InitialHandshakeBufferSize).ConfigureAwait(false); 463_sslAuthenticationOptions.UserState, cancellationToken).ConfigureAwait(false); 740await TIOAdapter.ReadAsync(InnerStream, Memory<byte>.Empty, cancellationToken).ConfigureAwait(false); 755int bytesRead = await TIOAdapter.ReadAsync(InnerStream, _buffer.AvailableMemory, cancellationToken).ConfigureAwait(false); 863int payloadBytes = await EnsureFullTlsFrameAsync<TIOAdapter>(cancellationToken, ReadBufferSize).ConfigureAwait(false);
System\Net\StreamFramer.cs (2)
35stream, buffer, buffer.Length, throwOnEndOfStream: false, cancellationToken).ConfigureAwait(false); 60stream, buffer, buffer.Length, throwOnEndOfStream: false, cancellationToken).ConfigureAwait(false);
System.Net.ServerSentEvents (3)
System\Net\ServerSentEvents\SseParser_1.cs (3)
189while (await FillLineBufferAsync(cancellationToken).ConfigureAwait(false) != 0 && _lineLength < Utf8Bom.Length) ; 239await FillLineBufferAsync(cancellationToken).ConfigureAwait(false); 503int bytesRead = await _stream.ReadAsync(_lineBuffer.AsMemory(offset), cancellationToken).ConfigureAwait(false);
System.Net.Sockets (3)
System\Net\Sockets\SocketPal.Unix.cs (1)
2096bytesTransferred = await socket.SendAsync(e.MemoryBuffer.Value, SocketFlags.None, cancellationToken).ConfigureAwait(false) + bytesTransferred;
System\Net\Sockets\TCPListener.cs (1)
243new TcpClient(await task.ConfigureAwait(false));
System\Net\Sockets\UDPClient.cs (1)
652SocketReceiveFromResult result = await task.ConfigureAwait(false);
System.Net.WebClient (2)
System\Net\WebClient.cs (2)
903int bytesRead = await readStream.ReadAsync(new Memory<byte>(copyBuffer)).ConfigureAwait(false); 1036int bytesRead = await readStream.ReadAsync(new Memory<byte>(buffer)).ConfigureAwait(false);
System.Net.WebSockets (6)
System\Net\WebSockets\ManagedWebSocket.cs (4)
820await _stream.ReadAsync(Memory<byte>.Empty, cancellationToken).ConfigureAwait(false); 933readBuffer, bytesToRead, throwOnEndOfStream: false, cancellationToken).ConfigureAwait(false); 1479await receiveTask.ConfigureAwait(false); 1592_receiveBuffer.Slice(_receiveBufferCount), bytesToRead, throwOnEndOfStream: false, cancellationToken).ConfigureAwait(false);
System\Net\WebSockets\WebSocketStream.cs (2)
228ValueWebSocketReceiveResult result = await WebSocket.ReceiveAsync(buffer, cancellationToken).ConfigureAwait(false); 351ValueWebSocketReceiveResult result = await WebSocket.ReceiveAsync(buffer, cancellationToken).ConfigureAwait(false);
System.Private.CoreLib (26)
src\libraries\System.Private.CoreLib\src\System\IO\BufferedStream.cs (2)
711return await _stream.ReadAsync(buffer, cancellationToken).ConfigureAwait(false) + bytesAlreadySatisfied; 716_readLen = await _stream.ReadAsync(new Memory<byte>(_buffer, 0, _bufferSize), cancellationToken).ConfigureAwait(false);
src\libraries\System.Private.CoreLib\src\System\IO\File.cs (5)
1110int read = await sr.ReadAsync(new Memory<char>(buffer), cancellationToken).ConfigureAwait(false); 1206int n = await RandomAccess.ReadAtOffsetAsync(sfh, bytes.AsMemory(index), index, cancellationToken).ConfigureAwait(false); 1245int n = await RandomAccess.ReadAtOffsetAsync(sfh, rentedArray.AsMemory(bytesRead), bytesRead, cancellationToken).ConfigureAwait(false); 1314while ((line = await sr.ReadLineAsync(cancellationToken).ConfigureAwait(false)) != null) 1640while ((line = await sr.ReadLineAsync(cts.Token).ConfigureAwait(false)) is not null)
src\libraries\System.Private.CoreLib\src\System\IO\Strategies\BufferedFileStreamStrategy.cs (3)
381return await _strategy.ReadAsync(destination, cancellationToken).ConfigureAwait(false); 440return await _strategy.ReadAsync(buffer, cancellationToken).ConfigureAwait(false) + bytesAlreadySatisfied; 445_readLen = await _strategy.ReadAsync(new Memory<byte>(_buffer, 0, _bufferSize), cancellationToken).ConfigureAwait(false);
src\libraries\System.Private.CoreLib\src\System\IO\Stream.cs (2)
106while ((bytesRead = await source.ReadAsync(new Memory<byte>(buffer), cancellationToken).ConfigureAwait(false)) != 0) 433int read = await ReadAsync(buffer.Slice(totalRead), cancellationToken).ConfigureAwait(false);
src\libraries\System.Private.CoreLib\src\System\IO\StreamReader.cs (9)
906if (_charPos == _charLen && (await ReadBufferAsync(cancellationToken).ConfigureAwait(false)) == 0) 944if (charPos < charLen || (await ReadBufferAsync(cancellationToken).ConfigureAwait(false)) > 0) 972while (await ReadBufferAsync(cancellationToken).ConfigureAwait(false) > 0); 1041await ReadBufferAsync(cancellationToken).ConfigureAwait(false); 1097if (_charPos == _charLen && (await ReadBufferAsync(cancellationToken).ConfigureAwait(false)) == 0) 1140int len = await tmpStream.ReadAsync(new Memory<byte>(tmpByteBuffer, tmpBytePos, tmpByteBuffer.Length - tmpBytePos), cancellationToken).ConfigureAwait(false); 1176_byteLen = await tmpStream.ReadAsync(new Memory<byte>(tmpByteBuffer), cancellationToken).ConfigureAwait(false); 1335int len = await tmpStream.ReadAsync(tmpByteBuffer.AsMemory(tmpBytePos), cancellationToken).ConfigureAwait(false); 1349_byteLen = await tmpStream.ReadAsync(new Memory<byte>(tmpByteBuffer), cancellationToken).ConfigureAwait(false);
src\libraries\System.Private.CoreLib\src\System\IO\TextReader.cs (2)
248while ((len = await ReadAsyncInternal(chars, cancellationToken).ConfigureAwait(false)) != 0) 318i = await ReadAsyncInternal(buffer.Slice(n), cancellationToken).ConfigureAwait(false);
src\libraries\System.Private.CoreLib\src\System\Runtime\CompilerServices\ConfiguredCancelableAsyncEnumerable.cs (1)
69_enumerator.MoveNextAsync().ConfigureAwait(_continueOnCapturedContext);
src\libraries\System.Private.CoreLib\src\System\Text\TranscodingStream.cs (1)
404int innerBytesReadJustNow = await _innerStream.ReadAsync(rentedBytes.AsMemory(0, DefaultReadByteBufferSize), cancellationToken).ConfigureAwait(false);
src\libraries\System.Private.CoreLib\src\System\Threading\Tasks\TaskAsyncEnumerableExtensions.ToBlockingEnumerable.cs (1)
47(mres ??= new ManualResetEventWithAwaiterSupport()).Wait(moveNextTask.ConfigureAwait(false).GetAwaiter());
System.Private.Xml (12)
System\Xml\Core\XmlTextReaderImplAsync.cs (12)
684var tuple_0 = await ParseTextAsync(orChars).ConfigureAwait(false); 914int read = await stream.ReadAtLeastAsync(_ps.bytes.AsMemory(_ps.bytesUsed), bytesToRead, throwOnEndOfStream: false).ConfigureAwait(false); 1127int read = await _ps.stream.ReadAsync(_ps.bytes.AsMemory(_ps.bytesUsed)).ConfigureAwait(false); 1149charsRead = await _ps.textReader.ReadAsync(_ps.chars.AsMemory(_ps.charsUsed, _ps.chars.Length - _ps.charsUsed - 1)).ConfigureAwait(false); 2959tuple_9 = await ParseTextAsync(orChars).ConfigureAwait(false); 3007tuple_11 = await ParseTextAsync(orChars).ConfigureAwait(false); 3053var tuple_12 = await ParseTextAsync(orChars).ConfigureAwait(false); 3077tuple_13 = await ParseTextAsync(orChars).ConfigureAwait(false); 3539var tuple_15 = await ParseTextAsync(orChars).ConfigureAwait(false); 3548tuple_15 = await ParseTextAsync(orChars).ConfigureAwait(false); 3618tuple_16 = await ParseTextAsync(orChars).ConfigureAwait(false); 5405var tuple_36 = await ParseTextAsync(orChars).ConfigureAwait(false);
System.Private.Xml.Linq (2)
System\Xml\Linq\XContainer.cs (2)
861while (await cr.ReadContentFromAsync(this, r).ConfigureAwait(false) && await r.ReadAsync().ConfigureAwait(false)); 878while (await cr.ReadContentFromContainerAsync(this, r).ConfigureAwait(false) && await r.ReadAsync().ConfigureAwait(false));
System.Security.Cryptography (8)
System\Security\Cryptography\CryptoStream.cs (4)
243return await ReadAsyncCore(buffer, cancellationToken, useAsync: true).ConfigureAwait(false); 351await _stream.ReadAsync(new Memory<byte>(tempInputBuffer, _inputBufferIndex, numWholeBlocksInBytes - _inputBufferIndex), cancellationToken).ConfigureAwait(false) : 428await _stream.ReadAsync(new Memory<byte>(_inputBuffer, _inputBufferIndex, _inputBlockSize - _inputBufferIndex), cancellationToken).ConfigureAwait(false) : 730bytesRead = await ReadAsync(rentedBuffer.AsMemory(0, bufferSize), cancellationToken).ConfigureAwait(false);
System\Security\Cryptography\HashAlgorithm.cs (1)
138while ((bytesRead = await inputStream.ReadAsync(buffer, cancellationToken).ConfigureAwait(false)) > 0)
System\Security\Cryptography\LiteHashProvider.cs (2)
154while ((read = await source.ReadAsync(rented, cancellationToken).ConfigureAwait(false)) > 0) 177int written = await ProcessStreamAsync(hash, source, result, cancellationToken).ConfigureAwait(false);
System\Security\Cryptography\LiteHashProvider.Xof.cs (1)
139while ((read = await source.ReadAsync(rented, cancellationToken).ConfigureAwait(false)) > 0)
System.Security.Cryptography.Cose (1)
System\Security\Cryptography\Cose\CoseMessage.cs (1)
476while ((bytesRead = await content.ReadAsync(contentBuffer, cancellationToken).ConfigureAwait(false)) > 0)
System.Text.Json (12)
System\Text\Json\Document\JsonDocument.Parse.cs (4)
223ArraySegment<byte> drained = await ReadToEndAsync(utf8Json, cancellationToken).ConfigureAwait(false); 247ArraySegment<byte> drained = await ReadToEndAsync(utf8Json, cancellationToken).ConfigureAwait(false); 911lastRead = await stream.ReadAsync(rented.AsMemory(written, utf8BomLength - written), cancellationToken).ConfigureAwait(false); 934lastRead = await stream.ReadAsync(rented.AsMemory(written), cancellationToken).ConfigureAwait(false);
System\Text\Json\Serialization\JsonSerializer.Read.Stream.cs (1)
497bufferState = await bufferState.ReadFromStreamAsync(utf8Json, cancellationToken, fillBuffer: false).ConfigureAwait(false);
System\Text\Json\Serialization\Metadata\JsonTypeInfoOfT.ReadHelper.cs (2)
39bufferState = await bufferState.ReadFromStreamAsync(utf8Json, cancellationToken).ConfigureAwait(false); 104T? result = await DeserializeAsync(utf8Json, cancellationToken).ConfigureAwait(false);
System\Text\Json\Serialization\Metadata\JsonTypeInfoOfT.WriteHelpers.cs (2)
120FlushResult result = await pipeWriter.FlushAsync(cancellationToken).ConfigureAwait(false); 182FlushResult result = await pipeWriter.FlushAsync(cancellationToken).ConfigureAwait(false);
System\Text\Json\Serialization\ReadBufferState.cs (1)
73int bytesRead = await utf8Json.ReadAsync(bufferState._buffer.AsMemory(bufferState._count), cancellationToken).ConfigureAwait(false);
System\Text\Json\Serialization\WriteStack.cs (2)
353exception = await DisposeFrame(Current.CollectionEnumerator, Current.AsyncDisposable, exception).ConfigureAwait(false); 358exception = await DisposeFrame(_stack[i].CollectionEnumerator, _stack[i].AsyncDisposable, exception).ConfigureAwait(false);
System.Threading.Channels (3)
System\Threading\Channels\ChannelReader.cs (2)
83if (!await WaitToReadAsync(ct).ConfigureAwait(false)) 105while (await WaitToReadAsync(cancellationToken).ConfigureAwait(false))
System\Threading\Channels\ChannelWriter.cs (1)
56while (await WaitToWriteAsync(ct).ConfigureAwait(false))
System.Threading.RateLimiting (2)
System\Threading\RateLimiting\ChainedPartitionedRateLimiter.cs (1)
103lease = await _limiters[i].AcquireAsync(resource, permitCount, cancellationToken).ConfigureAwait(false);
System\Threading\RateLimiting\ChainedRateLimiter.cs (1)
124lease = await _limiters[i].AcquireAsync(permitCount, cancellationToken).ConfigureAwait(false);
System.Windows.Forms (1)
System\Windows\Forms\Control_InvokeAsync.cs (1)
246var returnValue = await callback(cancellationToken).ConfigureAwait(false);
Test.Utilities (13)
src\Compilers\Core\Portable\Hashing\NonCryptographicHashAlgorithm.cs (1)
165int read = await stream.ReadAsync(buffer.AsMemory(), cancellationToken).ConfigureAwait(false);
src\Dependencies\Collections\Extensions\IEnumerableExtensions.cs (4)
483builder.Add(await selector(item).ConfigureAwait(false)); 498builder.Add(await selector(item, cancellationToken).ConfigureAwait(false)); 513builder.Add(await selector(item, arg, cancellationToken).ConfigureAwait(false)); 525builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
src\Dependencies\Collections\Extensions\ImmutableArrayExtensions.cs (3)
427builder[i] = await selector(array[i], cancellationToken).ConfigureAwait(false); 445builder[i] = await selector(array[i], arg, cancellationToken).ConfigureAwait(false); 471builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
src\Dependencies\Threading\AsyncBatchingWorkQueue`2.cs (1)
220return (ranToCompletion: true, await ProcessNextBatchAsync().ConfigureAwait(false));
src\Dependencies\Threading\ValueTaskExtensions.cs (2)
237_task.ConfigureAwait(_captureContext).GetAwaiter().OnCompleted(continuation); 247_task.ConfigureAwait(_captureContext).GetAwaiter().UnsafeOnCompleted(continuation);
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Utilities\IAsyncEnumerableExtensions.cs (1)
84while (await reader.WaitToReadAsync(cancellationToken).ConfigureAwait(false))
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Utilities\ProducerConsumer.cs (1)
47while (await reader.WaitToReadAsync(cancellationToken).ConfigureAwait(false))
TestDiscoveryWorker (1)
Program.cs (1)
123while (await _channel.Reader.WaitToReadAsync(CancellationToken.None).ConfigureAwait(false))
Text.Analyzers (59)
src\Dependencies\Collections\Extensions\IEnumerableExtensions.cs (4)
483builder.Add(await selector(item).ConfigureAwait(false)); 498builder.Add(await selector(item, cancellationToken).ConfigureAwait(false)); 513builder.Add(await selector(item, arg, cancellationToken).ConfigureAwait(false)); 525builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
src\Dependencies\Collections\Extensions\ImmutableArrayExtensions.cs (3)
427builder[i] = await selector(array[i], cancellationToken).ConfigureAwait(false); 445builder[i] = await selector(array[i], arg, cancellationToken).ConfigureAwait(false); 471builder.AddRange(await selector(item, arg, cancellationToken).ConfigureAwait(false));
src\Dependencies\Threading\AsyncBatchingWorkQueue`2.cs (1)
220return (ranToCompletion: true, await ProcessNextBatchAsync().ConfigureAwait(false));
src\Dependencies\Threading\ValueTaskExtensions.cs (2)
237_task.ConfigureAwait(_captureContext).GetAwaiter().OnCompleted(continuation); 247_task.ConfigureAwait(_captureContext).GetAwaiter().UnsafeOnCompleted(continuation);
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Utilities\IAsyncEnumerableExtensions.cs (1)
84while (await reader.WaitToReadAsync(cancellationToken).ConfigureAwait(false))
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Utilities\ProducerConsumer.cs (1)
47while (await reader.WaitToReadAsync(cancellationToken).ConfigureAwait(false))
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\AddImport\AddImportPlacementOptionsProviders.cs (1)
29var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeCleanup\CodeCleanupOptionsProviders.cs (1)
29var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeFixes\ForkingSyntaxEditorBasedCodeFixProvider.cs (1)
99changedRoot, cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeFixes\SyntaxEditorBasedCodeFixProvider.cs (1)
83var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeGeneration\AbstractCodeGenerationService.cs (2)
244var codeGenOptions = await oldDocument.GetCodeGenerationOptionsAsync(cancellationToken).ConfigureAwait(false); 256var addImportsOptions = await newDocument.GetAddImportPlacementOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeGeneration\CleanCodeGenerationOptions.cs (2)
42GenerationOptions = await document.GetCodeGenerationOptionsAsync(cancellationToken).ConfigureAwait(false), 43CleanupOptions = await document.GetCodeCleanupOptionsAsync(cancellationToken).ConfigureAwait(false)
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeGeneration\CodeGenerationOptionsProviders.cs (2)
36var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false); 44var options = await GetCodeGenerationOptionsAsync(document, cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\CodeRefactorings\CodeRefactoringContextExtensions.cs (4)
46var parsedDocument = await ParsedDocument.CreateAsync(context.Document, context.CancellationToken).ConfigureAwait(false); 55var parsedDocument = await ParsedDocument.CreateAsync(context.Document, context.CancellationToken).ConfigureAwait(false); 61var parsedDocument = await ParsedDocument.CreateAsync(document, cancellationToken).ConfigureAwait(false); 84var parsedDocument = await ParsedDocument.CreateAsync(document, cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Editing\ImportAdderService.cs (5)
37var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 120var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 121var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 180var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 183var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Extensions\DocumentExtensions.cs (3)
132var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 136return await ReuseExistingSpeculativeModelAsync(document, node, cancellationToken).ConfigureAwait(false); 225var syntaxTree = await document.GetRequiredSyntaxTreeAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Formatting\DocumentFormattingOptionsProviders.cs (1)
24var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Formatting\LineFormattingOptionsProviders.cs (1)
19var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Formatting\SyntaxFormattingOptionsProviders.cs (1)
22var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\LanguageServices\InitializeParameter\AbstractInitializerParameterService.cs (2)
119var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 123var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\LanguageServices\RemoveUnnecessaryImports\AbstractRemoveUnnecessaryImportsService.cs (2)
27var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 34var currentModel = await current.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\NamingStyles\NamingStylePreferencesProviders.cs (1)
17var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Options\MemberDisplayOptions.cs (1)
52var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\SemanticModelReuse\SemanticModelWorkspaceServiceFactory.SemanticModelWorkspaceService.cs (2)
104return await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 159var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Simplification\AbstractSimplificationService.cs (6)
69var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 96var root = (TCompilationUnitSyntax)await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 107root = (TCompilationUnitSyntax)await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 165var semanticModel = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 236semanticModelForReduce = await newDocument.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false); 291var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Simplification\SimplifierOptionsProviders.cs (1)
22var configOptions = await document.GetHostAnalyzerConfigOptionsAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Utilities\ParsedDocument.cs (2)
33var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 34var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Utilities\SemanticDocument.cs (3)
20var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 21var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false); 22var model = await document.GetRequiredSemanticModelAsync(cancellationToken).ConfigureAwait(false);
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Utilities\SyntacticDocument.cs (2)
30var text = await document.GetValueTextAsync(cancellationToken).ConfigureAwait(false); 31var root = await document.GetRequiredSyntaxRootAsync(cancellationToken).ConfigureAwait(false);