2331 references to Action
aspire (3)
Interaction\ConsoleInteractionService.cs (1)
44public void ShowStatus(string statusText, Action action)
Interaction\ExtensionInteractionService.cs (1)
74public void ShowStatus(string statusText, Action action)
Interaction\IInteractionService.cs (1)
12void ShowStatus(string statusText, Action action);
Aspire.Azure.Data.Tables.Tests (4)
DataTablesPublicApiTests.cs (4)
17var action = () => builder.AddAzureTableServiceClient(connectionName); 31var action = () => builder.AddAzureTableServiceClient(connectionName); 45var action = () => builder.AddKeyedAzureTableServiceClient(name); 59var action = () => builder.AddKeyedAzureTableServiceClient(name);
Aspire.Azure.Messaging.EventHubs.Tests (20)
MessagingEventHubsPublicApiTests.cs (20)
17var action = () => builder.AddAzureEventProcessorClient(connectionName); 31var action = () => builder.AddAzureEventProcessorClient(connectionName); 45var action = () => builder.AddKeyedAzureEventProcessorClient(name); 59var action = () => builder.AddKeyedAzureEventProcessorClient(name); 73var action = () => builder.AddAzurePartitionReceiverClient(connectionName); 87var action = () => builder.AddAzurePartitionReceiverClient(connectionName); 101var action = () => builder.AddKeyedAzurePartitionReceiverClient(name); 115var action = () => builder.AddKeyedAzurePartitionReceiverClient(name); 129var action = () => builder.AddAzureEventHubProducerClient(connectionName); 143var action = () => builder.AddAzureEventHubProducerClient(connectionName); 157var action = () => builder.AddKeyedAzureEventHubProducerClient(name); 171var action = () => builder.AddKeyedAzureEventHubProducerClient(name); 185var action = () => builder.AddAzureEventHubBufferedProducerClient(connectionName); 199var action = () => builder.AddAzureEventHubBufferedProducerClient(connectionName); 213var action = () => builder.AddKeyedAzureEventHubBufferedProducerClient(name); 227var action = () => builder.AddKeyedAzureEventHubBufferedProducerClient(name); 241var action = () => builder.AddAzureEventHubConsumerClient(connectionName); 255var action = () => builder.AddAzureEventHubConsumerClient(connectionName); 269var action = () => builder.AddKeyedAzureEventHubConsumerClient(name); 283var action = () => builder.AddKeyedAzureEventHubConsumerClient(name);
Aspire.Azure.Messaging.ServiceBus.Tests (4)
MessagingServiceBusPublicApiTests.cs (4)
17var action = () => builder.AddAzureServiceBusClient(connectionName); 31var action = () => builder.AddAzureServiceBusClient(connectionName); 45var action = () => builder.AddKeyedAzureServiceBusClient(name); 59var action = () => builder.AddKeyedAzureServiceBusClient(name);
Aspire.Azure.Messaging.WebPubSub.Tests (5)
MessagingWebPubSubPublicApiTests.cs (5)
17var action = () => builder.AddAzureWebPubSubServiceClient(connectionName); 31var action = () => builder.AddAzureWebPubSubServiceClient(connectionName); 46var action = () => builder.AddKeyedAzureWebPubSubServiceClient(connectionName, serviceKey); 61var action = () => builder.AddKeyedAzureWebPubSubServiceClient(connectionName, serviceKey); 78var action = () => builder.AddKeyedAzureWebPubSubServiceClient(connectionName, serviceKey);
Aspire.Azure.Npgsql.EntityFrameworkCore.PostgreSQL.Tests (3)
AzureNpgsqlEntityFrameworkCorePostgreSQLPublicApiTests.cs (3)
18var action = () => builder.AddAzureNpgsqlDbContext<DbContext>(connectionName); 32var action = () => builder.AddAzureNpgsqlDbContext<DbContext>(connectionName); 45var action = () => builder.EnrichAzureNpgsqlDbContext<DbContext>();
Aspire.Azure.Npgsql.Tests (4)
NpgsqlPublicApiTests.cs (4)
17var action = () => builder.AddAzureNpgsqlDataSource(connectionName, configureSettings: ConfigureTokenCredentials); 31var action = () => builder.AddAzureNpgsqlDataSource(connectionName, configureSettings: ConfigureTokenCredentials); 45var action = () => builder.AddKeyedAzureNpgsqlDataSource(name, configureSettings: ConfigureTokenCredentials); 59var action = () => builder.AddKeyedAzureNpgsqlDataSource(name, configureSettings: ConfigureTokenCredentials);
Aspire.Azure.Search.Documents.Tests (4)
SearchDocumentsPublicApiTests.cs (4)
17var action = () => builder.AddAzureSearchClient(connectionName); 31var action = () => builder.AddAzureSearchClient(connectionName); 45var action = () => builder.AddKeyedAzureSearchClient(name); 59var action = () => builder.AddKeyedAzureSearchClient(name);
Aspire.Azure.Security.KeyVault.Tests (9)
AspireKeyVaultExtensionsTests.cs (3)
282var action = () => builder.AddKeyedAzureKeyVaultClient(name); 300var action = () => builder.AddKeyedAzureKeyVaultKeyClient(name); 318var action = () => builder.AddKeyedAzureKeyVaultCertificateClient(name);
SecurityKeyVaultPublicApiTests.cs (6)
18var action = () => builder.AddAzureKeyVaultClient(connectionName); 32var action = () => builder.AddAzureKeyVaultClient(connectionName); 46var action = () => builder.AddKeyedAzureKeyVaultClient(name); 60var action = () => builder.AddKeyedAzureKeyVaultClient(name); 74var action = () => configurationManager.AddAzureKeyVaultSecrets(connectionName); 88var action = () => configurationManager.AddAzureKeyVaultSecrets(connectionName);
Aspire.Azure.Storage.Blobs.Tests (4)
StorageBlobsPublicApiTests.cs (4)
17var action = () => builder.AddAzureBlobServiceClient(connectionName); 31var action = () => builder.AddAzureBlobServiceClient(connectionName); 45var action = () => builder.AddKeyedAzureBlobServiceClient(name); 59var action = () => builder.AddKeyedAzureBlobServiceClient(name);
Aspire.Azure.Storage.Queues.Tests (8)
StorageQueuesPublicApiTests.cs (8)
17var action = () => builder.AddAzureQueueServiceClient(connectionName); 31var action = () => builder.AddAzureQueueServiceClient(connectionName); 45var action = () => builder.AddKeyedAzureQueueServiceClient(name); 59var action = () => builder.AddKeyedAzureQueueServiceClient(name); 74var action = () => builder.AddAzureQueueServiceClient(connectionName); 90var action = () => builder.AddAzureQueueServiceClient(connectionName); 106var action = () => builder.AddKeyedAzureQueueServiceClient(name); 122var action = () => builder.AddKeyedAzureQueueServiceClient(name);
Aspire.Cli.Tests (7)
Commands\PublishCommandPromptingIntegrationTests.cs (1)
791public void ShowStatus(string statusText, Action action) => action();
Hosting\CliOrphanDetectorTests.cs (1)
238file sealed class HostLifetimeStub(Action stopImplementation) : IHostApplicationLifetime
TestServices\TestConsoleInteractionService.cs (1)
24public void ShowStatus(string statusText, Action action)
TestServices\TestExtensionBackchannel.cs (1)
13public Action? ConnectAsyncCallback { get; set; }
TestServices\TestExtensionInteractionService.cs (3)
17public Action? LaunchAppHostCallback { get; set; } 18public Action? NotifyAppHostStartupCompletedCallback { get; set; } 28public void ShowStatus(string statusText, Action action)
Aspire.Confluent.Kafka.Tests (10)
ConfluentKafkaPublicApiTests.cs (8)
27Action action = overrideIndex switch 63Action action = overrideIndex switch 95Action action = overrideIndex switch 131Action action = overrideIndex switch 163Action action = overrideIndex switch 199Action action = overrideIndex switch 231Action action = overrideIndex switch 267Action action = overrideIndex switch
ConsumerConfigurationTests.cs (1)
139Action act =
ProducerConfigurationTests.cs (1)
128Action act =
Aspire.Dashboard (4)
Otlp\Storage\Subscription.cs (2)
18private readonly Action _unsubscribe; 27public Subscription(string name, ResourceKey? resourceKey, SubscriptionType subscriptionType, Func<Task> callback, Action unsubscribe, ExecutionContext? executionContext, TelemetryRepository telemetryRepository)
Utils\DashboardUIHelpers.cs (1)
73public static async Task<Message> DisplayMaxLimitMessageAsync(IMessageService messageService, string title, string message, Action onClose)
Utils\FilterHelpers.cs (1)
24Action clearFilters,
Aspire.Dashboard.Components.Tests (1)
Shared\TestMessageService.cs (1)
20public event Action? OnMessageItemsUpdated;
Aspire.Hosting.Azure.Tests (19)
PublicApiTests\AppContainersPublicApiTests.cs (4)
79var action = () => 124var action = () => app.ConfigureCustomDomain(customDomain, certificateName); 139var action = () => app.ConfigureCustomDomain(customDomain, certificateName); 154var action = () => app.ConfigureCustomDomain(customDomain, certificateName);
PublicApiTests\ApplicationInsightsPublicApiTests.cs (2)
20Action action = overrideIndex switch 42Action action = overrideIndex switch
PublicApiTests\CosmosDBPublicApiTests.cs (1)
532var action = () =>
PublicApiTests\FunctionsPublicApiTests.cs (1)
72var action = () =>
PublicApiTests\PostgreSQLPublicApiTests.cs (2)
18var action = () => 33var action = () =>
PublicApiTests\RedisPublicApiTests.cs (3)
45var action = () => 60var action = () => 113var action = () =>
PublicApiTests\SignalRPublicApiTests.cs (2)
31Action action = overrideIndex switch 53Action action = overrideIndex switch
PublicApiTests\SqlPublicApiTests.cs (2)
64var action = () => 79var action = () =>
PublicApiTests\WebPubSubPublicApiTests.cs (2)
78Action action = overrideIndex switch 101Action action = overrideIndex switch
Aspire.Microsoft.Azure.Cosmos.Tests (4)
MicrosoftAzureCosmosPublicApiTests.cs (4)
17var action = () => builder.AddAzureCosmosClient(connectionName); 31var action = () => builder.AddAzureCosmosClient(connectionName); 45var action = () => builder.AddKeyedAzureCosmosClient(name); 59var action = () => builder.AddKeyedAzureCosmosClient(name);
Aspire.Microsoft.Data.SqlClient.Tests (4)
MicrosoftDataSqlClientPublicApiTests.cs (4)
17var action = () => builder.AddSqlServerClient(connectionName); 31var action = () => builder.AddSqlServerClient(connectionName); 45var action = () => builder.AddKeyedSqlServerClient(name); 59var action = () => builder.AddKeyedSqlServerClient(name);
Aspire.Microsoft.EntityFrameworkCore.Cosmos.Tests (4)
MicrosoftEntityFrameworkCoreCosmosPublicApiTests.cs (4)
19var action = () => builder.AddCosmosDbContext<DbContext>(connectionName, databaseName); 34var action = () => builder.AddCosmosDbContext<DbContext>(connectionName, databaseName); 51var action = () => builder.AddCosmosDbContext<DbContext>(connectionName, databaseName); 64var action = () => builder.EnrichCosmosDbContext<DbContext>();
Aspire.Microsoft.EntityFrameworkCore.SqlServer.Tests (3)
MicrosoftEntityFrameworkCoreSqlServerPublicApiTests.cs (3)
18var action = () => builder.AddSqlServerDbContext<DbContext>(connectionName); 32var action = () => builder.AddSqlServerDbContext<DbContext>(connectionName); 45var action = () => builder.EnrichSqlServerDbContext<DbContext>();
Aspire.Milvus.Client.Tests (4)
MilvusClientPublicApiTests.cs (4)
17var action = () => builder.AddMilvusClient(connectionName); 31var action = () => builder.AddMilvusClient(connectionName); 45var action = () => builder.AddKeyedMilvusClient(connectionName); 59var action = () => builder.AddKeyedMilvusClient(name);
Aspire.MongoDB.Driver.Tests (4)
MongoDBDriverPublicApiTests.cs (4)
17var action = () => builder.AddMongoDBClient(connectionName); 31var action = () => builder.AddMongoDBClient(connectionName); 45var action = () => builder.AddKeyedMongoDBClient(connectionName); 59var action = () => builder.AddKeyedMongoDBClient(name);
Aspire.MongoDB.Driver.v3.Tests (4)
tests\Aspire.MongoDB.Driver.Tests\MongoDBDriverPublicApiTests.cs (4)
17var action = () => builder.AddMongoDBClient(connectionName); 31var action = () => builder.AddMongoDBClient(connectionName); 45var action = () => builder.AddKeyedMongoDBClient(connectionName); 59var action = () => builder.AddKeyedMongoDBClient(name);
Aspire.MySqlConnector.Tests (4)
MySqlConnectorPublicApiTests.cs (4)
17var action = () => builder.AddMySqlDataSource(connectionName); 31var action = () => builder.AddMySqlDataSource(connectionName); 45var action = () => builder.AddKeyedMySqlDataSource(name); 59var action = () => builder.AddKeyedMySqlDataSource(name);
Aspire.NATS.Net.Tests (6)
NatsClientPublicApiTests.cs (6)
29Action action = overrideIndex switch 65Action action = overrideIndex switch 97Action action = overrideIndex switch 133Action action = overrideIndex switch 155var action = builder.AddNatsJetStream; 183Action action = (useKeyed, useConfigureSettings, useConfigureOptions, useConfigureOptionsWithServiceProvider) switch
Aspire.Npgsql.EntityFrameworkCore.PostgreSQL.Tests (3)
NpgsqlEntityFrameworkCorePostgreSQLPublicApiTests.cs (3)
18var action = () => builder.AddNpgsqlDbContext<DbContext>(connectionName); 32var action = () => builder.AddNpgsqlDbContext<DbContext>(connectionName); 45var action = () => builder.EnrichNpgsqlDbContext<DbContext>();
Aspire.Npgsql.Tests (4)
NpgsqlPublicApiTests.cs (4)
17var action = () => builder.AddNpgsqlDataSource(connectionName); 31var action = () => builder.AddNpgsqlDataSource(connectionName); 45var action = () => builder.AddKeyedNpgsqlDataSource(name); 59var action = () => builder.AddKeyedNpgsqlDataSource(name);
Aspire.Oracle.EntityFrameworkCore.Tests (3)
OracleEntityFrameworkCorePublicApiTests.cs (3)
18var action = () => builder.AddOracleDatabaseDbContext<DbContext>(connectionName); 32var action = () => builder.AddOracleDatabaseDbContext<DbContext>(connectionName); 45var action = () => builder.EnrichOracleDatabaseDbContext<DbContext>();
Aspire.Pomelo.EntityFrameworkCore.MySql.Tests (3)
PomeloEntityFrameworkCoreMySqlPublicApiTests.cs (3)
18var action = () => builder.AddMySqlDbContext<DbContext>(connectionName); 32var action = () => builder.AddMySqlDbContext<DbContext>(connectionName); 45var action = () => builder.EnrichMySqlDbContext<DbContext>();
Aspire.Qdrant.Client.Tests (4)
QdrantClientPublicApiTests.cs (4)
17var action = () => builder.AddQdrantClient(connectionName); 31var action = () => builder.AddQdrantClient(connectionName); 45var action = () => builder.AddKeyedQdrantClient(name); 59var action = () => builder.AddKeyedQdrantClient(name);
Aspire.RabbitMQ.Client.Tests (5)
AspireRabbitMQLoggingTests.cs (1)
242public Action? LoggedMessage { get; set; }
RabbitMQClientPublicApiTests.cs (4)
17var action = () => builder.AddRabbitMQClient(connectionName); 31var action = () => builder.AddRabbitMQClient(connectionName); 45var action = () => builder.AddKeyedRabbitMQClient(name); 59var action = () => builder.AddKeyedRabbitMQClient(name);
Aspire.RabbitMQ.Client.v7.Tests (1)
tests\Aspire.RabbitMQ.Client.Tests\AspireRabbitMQLoggingTests.cs (1)
242public Action? LoggedMessage { get; set; }
Aspire.Seq.Tests (2)
SeqPublicApiTests.cs (2)
17var action = () => builder.AddSeqEndpoint(connectionName); 31var action = () => builder.AddSeqEndpoint(connectionName);
Aspire.StackExchange.Redis (2)
src\Vendoring\OpenTelemetry.Instrumentation.StackExchangeRedis\StackExchangeRedisInstrumentation.cs (2)
81private readonly Action disposalAction; 84Action disposalAction)
Aspire.StackExchange.Redis.DistributedCaching.Tests (4)
StackExchangeRedisDistributedCachingPublicApiTests.cs (4)
17var action = () => builder.AddRedisDistributedCache(connectionName); 31var action = () => builder.AddRedisDistributedCache(connectionName); 45var action = () => builder.AddKeyedRedisDistributedCache(name); 59var action = () => builder.AddKeyedRedisDistributedCache(name);
Aspire.StackExchange.Redis.OutputCaching.Tests (4)
StackExchangeRedisOutputCachingPublicApiTests.cs (4)
17var action = () => builder.AddRedisOutputCache(connectionName); 31var action = () => builder.AddRedisOutputCache(connectionName); 45var action = () => builder.AddKeyedRedisOutputCache(name); 59var action = () => builder.AddKeyedRedisOutputCache(name);
Aspire.StackExchange.Redis.Tests (4)
StackExchangeRedisPublicApiTests.cs (4)
17var action = () => builder.AddRedisClient(connectionName); 31var action = () => builder.AddRedisClient(connectionName); 45var action = () => builder.AddKeyedRedisClient(name); 59var action = () => builder.AddKeyedRedisClient(name);
BasicWebSite (4)
Controllers\AsyncActionsController.cs (4)
198private readonly IList<Action> _continuations = new List<Action>(); 209foreach (var continuation in _continuations) 221public void OnCompleted(Action continuation)
BinaryFormatTests (3)
FormatTests\FormattedObject\HashTableTests.cs (1)
121Action action = () => BinaryFormatWriter.WritePrimitiveHashtable(stream, hashtable);
FormatTests\FormattedObject\NullRecordTests.cs (1)
18Action action = () => objectNull.Write(writer);
FormatTests\FormattedObject\RecordMapTests.cs (1)
21Action action = () => map.AddRecord(new Record());
ClientSample (6)
Tcp\SocketAwaitable.cs (6)
18private static readonly Action _callbackCompleted = () => { }; 22private Action _callback; 48public void OnCompleted(Action continuation) 57public void UnsafeOnCompleted(Action continuation) 66var continuation = Interlocked.Exchange(ref _callback, _callbackCompleted); 70_ioScheduler.Schedule(state => ((Action)state)(), continuation);
ConfigurationSchemaGenerator.Tests (2)
VariousTypes.cs (2)
71/// A value of type <see cref="Action"/> (ignored). 73public Action? PropertyOfAction { get; set; }
dotnet-dev-certs (1)
src\Tools\Shared\CommandLine\CommandLineApplicationExtensions.cs (1)
18public static void OnExecute(this CommandLineApplication app, Action action)
dotnet-getdocument (1)
src\Tools\Shared\CommandLine\CommandLineApplicationExtensions.cs (1)
18public static void OnExecute(this CommandLineApplication app, Action action)
dotnet-openapi (1)
src\Tools\Shared\CommandLine\CommandLineApplicationExtensions.cs (1)
18public static void OnExecute(this CommandLineApplication app, Action action)
dotnet-sql-cache (1)
src\Tools\Shared\CommandLine\CommandLineApplicationExtensions.cs (1)
18public static void OnExecute(this CommandLineApplication app, Action action)
dotnet-svcutil-lib (25)
CommandProcessorOptions.cs (1)
991private static void ProcessToolArg(Action action)
FrameworkFork\Microsoft.Xml\Xml\AsyncHelper.cs (2)
30public static Task CallVoidFuncWhenFinish(this Task task, Action func) 43private static async Task _CallVoidFuncWhenFinish(this Task task, Action func)
FrameworkFork\System.ServiceModel\Internals\System\Runtime\AsyncResult.cs (2)
24private Action _beforePrepareAsyncCompletionAction; 244protected void SetBeforePrepareAsyncCompletionAction(Action beforePrepareAsyncCompletionAction)
FrameworkFork\System.ServiceModel\Internals\System\Runtime\InputQueue.cs (14)
319public void EnqueueAndDispatch(T item, Action dequeuedCallback) 324public void EnqueueAndDispatch(Exception exception, Action dequeuedCallback, bool canDispatchOnThisThread) 330public void EnqueueAndDispatch(T item, Action dequeuedCallback, bool canDispatchOnThisThread) 336public bool EnqueueWithoutDispatch(T item, Action dequeuedCallback) 342public bool EnqueueWithoutDispatch(Exception exception, Action dequeuedCallback) 543private static void InvokeDequeuedCallback(Action dequeuedCallback) 551private static void InvokeDequeuedCallbackLater(Action dequeuedCallback) 573Action dequeuedCallback = (Action)state; 747private Action _dequeuedCallback; 751public Item(T value, Action dequeuedCallback) 756public Item(Exception exception, Action dequeuedCallback) 761private Item(T value, Exception exception, Action dequeuedCallback) 768public Action DequeuedCallback
FrameworkFork\System.ServiceModel\Internals\System\Runtime\TaskHelpers.cs (1)
289public void OnCompleted(Action continuation)
FrameworkFork\System.ServiceModel\System\ServiceModel\Dispatcher\DuplexChannelBinder.cs (1)
1039private Action _messageDequeuedCallback;
Shared\Utilities\AsyncHelper.cs (4)
16public static async Task RunAsync(Action action, CancellationToken cancellationToken) 21public static async Task RunAsync(Action action, Action onCancellation, CancellationToken cancellationToken) 43public static async Task<T> RunAsync<T>(Func<T> func, Action onCancellation, CancellationToken cancellationToken)
dotnet-user-jwts (1)
src\Tools\Shared\CommandLine\CommandLineApplicationExtensions.cs (1)
18public static void OnExecute(this CommandLineApplication app, Action action)
dotnet-user-secrets (1)
src\Tools\Shared\CommandLine\CommandLineApplicationExtensions.cs (1)
18public static void OnExecute(this CommandLineApplication app, Action action)
GenerateDocumentationAndConfigFiles (15)
src\Dependencies\PooledObjects\PooledDelegates.cs (5)
37/// Gets an <see cref="Action"/> delegate, which calls <paramref name="unboundAction"/> with the specified 65public static Releaser GetPooledAction<TArg>(Action<TArg> unboundAction, TArg argument, out Action boundAction) 66=> GetPooledDelegate<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action>(unboundAction, argument, out boundAction); 384: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action> 386protected override Action Bind()
src\Dependencies\Threading\ConfiguredYieldAwaitable.cs (3)
36static continuation => ((Action)continuation!)(); 52public void OnCompleted(Action continuation) 66public void UnsafeOnCompleted(Action continuation)
src\Dependencies\Threading\TaskExtensions.cs (2)
104public void OnCompleted(Action continuation) 114public void UnsafeOnCompleted(Action continuation)
src\Dependencies\Threading\ValueTaskExtensions.cs (4)
135public void OnCompleted(Action continuation) 145public void UnsafeOnCompleted(Action continuation) 235public void OnCompleted(Action continuation) 245public void UnsafeOnCompleted(Action continuation)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Extensions\Compilation\CompilationExtensions.cs (1)
136=> compilation.GetTypeByMetadataName(typeof(Action).FullName!);
GetDocument.Insider (1)
src\Tools\Shared\CommandLine\CommandLineApplicationExtensions.cs (1)
18public static void OnExecute(this CommandLineApplication app, Action action)
IdeBenchmarks (1)
InheritanceMargin\InheritanceMarginGlyphBenchmarks.cs (1)
149private void RunOnUIThread(Action action)
IIS.Tests (1)
Utilities\TestServer.cs (1)
210private void Retry(Action func, int attempts)
InteropClient (1)
Assert.cs (1)
81public static TException Throws<TException>(Action action) where TException : Exception
Metrics (15)
src\Dependencies\PooledObjects\PooledDelegates.cs (5)
37/// Gets an <see cref="Action"/> delegate, which calls <paramref name="unboundAction"/> with the specified 65public static Releaser GetPooledAction<TArg>(Action<TArg> unboundAction, TArg argument, out Action boundAction) 66=> GetPooledDelegate<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action>(unboundAction, argument, out boundAction); 384: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action> 386protected override Action Bind()
src\Dependencies\Threading\ConfiguredYieldAwaitable.cs (3)
36static continuation => ((Action)continuation!)(); 52public void OnCompleted(Action continuation) 66public void UnsafeOnCompleted(Action continuation)
src\Dependencies\Threading\TaskExtensions.cs (2)
104public void OnCompleted(Action continuation) 114public void UnsafeOnCompleted(Action continuation)
src\Dependencies\Threading\ValueTaskExtensions.cs (4)
135public void OnCompleted(Action continuation) 145public void UnsafeOnCompleted(Action continuation) 235public void OnCompleted(Action continuation) 245public void UnsafeOnCompleted(Action continuation)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Extensions\Compilation\CompilationExtensions.cs (1)
136=> compilation.GetTypeByMetadataName(typeof(Action).FullName!);
Metrics.Legacy (15)
src\Dependencies\PooledObjects\PooledDelegates.cs (5)
37/// Gets an <see cref="Action"/> delegate, which calls <paramref name="unboundAction"/> with the specified 65public static Releaser GetPooledAction<TArg>(Action<TArg> unboundAction, TArg argument, out Action boundAction) 66=> GetPooledDelegate<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action>(unboundAction, argument, out boundAction); 384: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action> 386protected override Action Bind()
src\Dependencies\Threading\ConfiguredYieldAwaitable.cs (3)
36static continuation => ((Action)continuation!)(); 52public void OnCompleted(Action continuation) 66public void UnsafeOnCompleted(Action continuation)
src\Dependencies\Threading\TaskExtensions.cs (2)
104public void OnCompleted(Action continuation) 114public void UnsafeOnCompleted(Action continuation)
src\Dependencies\Threading\ValueTaskExtensions.cs (4)
135public void OnCompleted(Action continuation) 145public void UnsafeOnCompleted(Action continuation) 235public void OnCompleted(Action continuation) 245public void UnsafeOnCompleted(Action continuation)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Extensions\Compilation\CompilationExtensions.cs (1)
136=> compilation.GetTypeByMetadataName(typeof(Action).FullName!);
Microsoft.Arcade.Test.Common (3)
AssertEx.cs (3)
344public static void ThrowsArgumentNull(string parameterName, Action del) 356public static void ThrowsArgumentException(string parameterName, Action del) 368public static T Throws<T>(Action del, bool allowDerived = false) where T : Exception
Microsoft.AspNetCore.Authentication.JwtBearer.Tools.Tests (1)
UserJwtsTestFixture.cs (1)
11private readonly Stack<Action> _disposables = new();
Microsoft.AspNetCore.Components (17)
CompilerServices\RuntimeHelpers.cs (2)
114public static void InvokeSynchronousDelegate(Action callback) 133public static Task InvokeAsynchronousDelegate(Action callback)
ComponentBase.cs (1)
205protected Task InvokeAsync(Action workItem)
Dispatcher.cs (2)
55/// Invokes the given <see cref="Action"/> in the context of the associated <see cref="Renderer"/>. 59public abstract Task InvokeAsync(Action workItem);
EventCallback.cs (1)
21public static readonly EventCallback Empty = new EventCallback(null, (Action)(() => { }));
EventCallbackFactory.cs (2)
35public EventCallback Create(object receiver, Action callback) 119public EventCallback<TValue> Create<TValue>(object receiver, Action callback)
EventCallbackOfT.cs (1)
16public static readonly EventCallback<TValue> Empty = new EventCallback<TValue>(null, (Action)(() => { }));
EventCallbackWorkItem.cs (1)
46case Action action:
PersistentComponentState.cs (1)
84public RestoringComponentStateSubscription RegisterOnRestoring(Action callback, RestoreOptions options)
PersistentState\RestoreComponentStateRegistration.cs (2)
6internal readonly struct RestoreComponentStateRegistration(Action callback) 8public Action Callback { get; } = callback;
Rendering\RendererSynchronizationContext.cs (2)
41public Task InvokeAsync(Action action) 60static void Execute((AsyncTaskMethodBuilder Completion, Action Action, RendererSynchronizationContext Context) state)
Rendering\RendererSynchronizationContextDispatcher.cs (1)
21public override Task InvokeAsync(Action workItem)
src\Components\Shared\src\HotReloadManager.cs (1)
22public event Action? OnDeltaApplied;
Microsoft.AspNetCore.Components.Authorization (1)
src\Components\Shared\src\HotReloadManager.cs (1)
22public event Action? OnDeltaApplied;
Microsoft.AspNetCore.Components.Authorization.Tests (2)
src\Components\Shared\test\TestRenderer.cs (2)
35public Action OnExceptionHandled { get; set; } 39public Action OnUpdateDisplayComplete { get; set; }
Microsoft.AspNetCore.Components.Endpoints (1)
src\Components\Shared\src\HotReloadManager.cs (1)
22public event Action? OnDeltaApplied;
Microsoft.AspNetCore.Components.Endpoints.Tests (4)
EndpointHtmlRendererTest.cs (2)
999var handler = () => { invoked = true; }; 1658public Action Handler { get; set; }
ImportMapTest.cs (2)
263public Action OnExceptionHandled { get; set; } 267public Action OnUpdateDisplayComplete { get; set; }
Microsoft.AspNetCore.Components.Forms (2)
EditContextDataAnnotationsExtensions.cs (1)
56private static event Action? OnClearCache;
src\Components\Shared\src\HotReloadManager.cs (1)
22public event Action? OnDeltaApplied;
Microsoft.AspNetCore.Components.Forms.Tests (2)
src\Components\Shared\test\TestRenderer.cs (2)
35public Action OnExceptionHandled { get; set; } 39public Action OnUpdateDisplayComplete { get; set; }
Microsoft.AspNetCore.Components.QuickGrid.Tests (2)
src\Components\Shared\test\TestRenderer.cs (2)
35public Action OnExceptionHandled { get; set; } 39public Action OnUpdateDisplayComplete { get; set; }
Microsoft.AspNetCore.Components.Server.Tests (3)
Circuits\CircuitHostTest.cs (1)
1124public Action OnAfterRenderComplete { get; set; }
Circuits\CircuitRegistryTest.cs (1)
582public Action OnAfterEntryEvicted { get; set; }
Circuits\RemoteRendererTest.cs (1)
748public Action OnAfterRenderComplete { get; set; }
Microsoft.AspNetCore.Components.Tests (79)
CascadingParameterStateTest.cs (1)
439renderer.Dispatcher.InvokeAsync((Action)(() => supplier.SetParametersAsync(ParameterView.FromDictionary(supplierParams))));
EventCallbackFactoryTest.cs (18)
13var @delegate = (Action)component.SomeAction; 32var @delegate = (Action)component.SomeAction; 48var @delegate = (Action)component.SomeAction; 66var @delegate = (Action)(() => { }); 86var callback = EventCallback.Factory.Create(component, (Action)null); 300var @delegate = (Action)component.SomeAction; 319var @delegate = (Action)component.SomeAction; 335var @delegate = (Action)component.SomeAction; 353var @delegate = (Action)(() => { }); 373var callback = EventCallback.Factory.Create<string>(component, (Action)null);
EventCallbackTest.cs (6)
35var callback = new EventCallback(null, (Action)(() => runCount++)); 49var callback = new EventCallback<EventArgs>(null, (Action)(() => runCount++)); 65var callback = new EventCallback(component, (Action)(() => runCount++)); 82var callback = new EventCallback(component, (Action)(() => runCount++)); 299var callback = new EventCallback<EventArgs>(component, (Action)(() => runCount++)); 316var callback = new EventCallback<EventArgs>(component, (Action)(() => runCount++));
PersistentValueProviderComponentSubscriptionTests.cs (1)
516public override Task InvokeAsync(Action workItem)
RendererTest.cs (29)
1021builder.AddComponentParameter(1, nameof(EventComponent.OnClickAction), (Action)parentComponent.SomeMethod); 1062builder.AddComponentParameter(1, nameof(EventComponent.OnClickAction), (Action)(() => 1104builder.AddComponentParameter(1, nameof(EventComponent.OnClickEventCallback), EventCallback.Factory.Create(parentComponent, (Action)parentComponent.SomeMethod)); 1142builder.AddComponentParameter(1, nameof(EventComponent.OnClickEventCallback), EventCallback.Factory.Create(parentComponent, (Action)(() => 1223builder.AddComponentParameter(1, nameof(EventComponent.OnClickEventCallbackOfT), EventCallback.Factory.Create<DerivedEventArgs>(parentComponent, (Action)parentComponent.SomeMethod)); 1261builder.AddComponentParameter(1, nameof(EventComponent.OnClickEventCallbackOfT), EventCallback.Factory.Create<DerivedEventArgs>(parentComponent, (Action)(() => 1341builder.AddComponentParameter(1, nameof(EventComponent.OnClickAction), (Action)(() => 1374builder.AddComponentParameter(1, nameof(EventComponent.OnClickEventCallback), EventCallback.Factory.Create(parentComponent, (Action)(() => 1442builder.AddComponentParameter(1, nameof(EventComponent.OnClickAction), (Action)(() => 1475builder.AddComponentParameter(1, nameof(EventComponent.OnClickEventCallback), EventCallback.Factory.Create(parentComponent, (Action)(() => 1544builder.AddComponentParameter(1, nameof(EventComponent.OnClickAction), (Action)(() => 1577builder.AddComponentParameter(1, nameof(EventComponent.OnClickEventCallback), EventCallback.Factory.Create(parentComponent, (Action)(() => 2280builder.AddComponentParameter(1, nameof(DisposableComponent.DisposeAction), (Action)(() => throw exception1)); 2284builder.AddComponentParameter(1, nameof(DisposableComponent.DisposeAction), (Action)(() => throw exception2)); 2563builder.AddComponentParameter(1, nameof(DisposableComponent.DisposeAction), (Action)(() => { count1++; })); 2567builder.AddComponentParameter(1, nameof(DisposableComponent.DisposeAction), (Action)(() => { count2++; throw exception1; })); 2571builder.AddComponentParameter(1, nameof(DisposableComponent.DisposeAction), (Action)(() => { count3++; })); 2576builder.AddComponentParameter(1, nameof(DisposableComponent.DisposeAction), (Action)(() => { count4++; throw exception2; })); 2580builder.AddComponentParameter(1, nameof(DisposableComponent.DisposeAction), (Action)(() => { count5++; })); 4242builder.AddComponentParameter(1, nameof(DisposableComponent.DisposeAction), (Action)(() => throw exception1)); 4246builder.AddComponentParameter(1, nameof(DisposableComponent.DisposeAction), (Action)(() => throw exception2)); 4907builder.AddComponentParameter(1, nameof(DisposableComponent.DisposeAction), (Action)(() => throw exception1)); 5289public Action OnClickAction { get; set; } 5501public Action OnAfterRenderLogic { get; set; } 5528public Action DisposeAction { get; set; } 5616public Action OnEvent { get; set; } 5885public Action OnAfterRenderComplete { get; set; } 5929private readonly Action _callback; 5931public CallbackOnRenderComponent(Action callback)
Rendering\RendererSynchronizationContextTest.cs (2)
467var task = context.InvokeAsync((Action)(() => 483var task = context.InvokeAsync((Action)(() =>
Rendering\RenderTreeBuilderTest.cs (6)
1097var value = new Action(() => { }); 1119builder.AddAttribute(1, "attr", (Action)null); 1503var value = new Action(() => { }); 1523var value = new Action(() => { }); 1992builder.AddAttribute(0, "2", new EventCallback(null, (Action)(() => { }))); 2005{ "6", new EventCallback(null, (Action)(() =>{ })) },
RenderTreeUpdaterTest.cs (14)
20builder.AddAttribute(1, "eventname", (Action)(() => { })); 33frame => AssertFrame.Attribute(frame, "eventname", v => Assert.IsType<Action>(v), 1), 48builder.AddAttribute(1, "eventname", (Action)(() => { })); 61frame => AssertFrame.Attribute(frame, "eventname", v => Assert.IsType<Action>(v), 1), 73builder.AddAttribute(1, "eventname", (Action)(() => { })); 78builder.AddAttribute(4, "eventname", (Action)(() => { })); 94frame => AssertFrame.Attribute(frame, "eventname", v => Assert.IsType<Action>(v), 1), 97frame => AssertFrame.Attribute(frame, "eventname", v => Assert.IsType<Action>(v), 4), 111builder.AddAttribute(1, "eventname", (Action)(() => { })); 125frame => AssertFrame.Attribute(frame, "eventname", v => Assert.IsType<Action>(v), 1)); 136builder.AddAttribute(1, "eventname", (Action)(() => { })); 149frame => AssertFrame.Attribute(frame, "eventname", v => Assert.IsType<Action>(v), 1)); 164builder.AddAttribute(4, "eventname", (Action)(() => { })); 183frame => AssertFrame.Attribute(frame, "eventname", v => Assert.IsType<Action>(v), 4));
src\Components\Shared\test\TestRenderer.cs (2)
35public Action OnExceptionHandled { get; set; } 39public Action OnUpdateDisplayComplete { get; set; }
Microsoft.AspNetCore.Components.Web.Tests (2)
src\Components\Shared\test\TestRenderer.cs (2)
35public Action OnExceptionHandled { get; set; } 39public Action OnUpdateDisplayComplete { get; set; }
Microsoft.AspNetCore.Components.WebAssembly (5)
Hosting\WebAssemblyCallQueue.cs (2)
21private static readonly Queue<Action> _pendingWork = new(); 58while (_pendingWork.TryDequeue(out var nextWorkItem))
Rendering\NullDispatcher.cs (1)
16public override Task InvokeAsync(Action workItem)
Rendering\WebAssemblyDispatcher.cs (2)
18public override Task InvokeAsync(Action workItem) 36var state = ((TaskCompletionSource tcs, Action workItem))o!;
Microsoft.AspNetCore.Components.WebView.Maui (1)
MauiDispatcher.cs (1)
21 public override Task InvokeAsync(Action workItem)
Microsoft.AspNetCore.Components.WebView.Photino (4)
PhotinoDispatcher.cs (1)
23public override Task InvokeAsync(Action workItem)
PhotinoSynchronizationContext.cs (3)
59public Task InvokeAsync(Action action) 61var completion = new PhotinoSynchronizationTaskCompletionSource<Action, object>(action); 64var completion = (PhotinoSynchronizationTaskCompletionSource<Action, object>)state;
Microsoft.AspNetCore.Components.WebView.WindowsForms (3)
WindowsFormsDispatcher.cs (3)
41 public override async Task InvokeAsync(Action workItem) 82 Action action = async () => 150 Action action = async () =>
Microsoft.AspNetCore.Components.WebView.Wpf (1)
WpfDispatcher.cs (1)
26 public override async Task InvokeAsync(Action workItem)
Microsoft.AspNetCore.ConcurrencyLimiter.Tests (3)
TestUtils.cs (3)
73private Action _onExit { get; } 78public TestQueue(Func<TestQueue, Task<bool>> onTryEnter, Action onExit = null) 84public TestQueue(Func<TestQueue, bool> onTryEnter, Action onExit = null) :
Microsoft.AspNetCore.Cryptography.Internal.Tests (1)
src\DataProtection\shared\test\ExceptionAssert2.cs (1)
18public static CryptographicException ThrowsCryptographicException(Action testCode)
Microsoft.AspNetCore.Cryptography.KeyDerivation.Tests (1)
src\DataProtection\shared\test\ExceptionAssert2.cs (1)
18public static CryptographicException ThrowsCryptographicException(Action testCode)
Microsoft.AspNetCore.DataProtection.Extensions.Tests (1)
src\DataProtection\shared\test\ExceptionAssert2.cs (1)
18public static CryptographicException ThrowsCryptographicException(Action testCode)
Microsoft.AspNetCore.DataProtection.Tests (3)
HostingTests.cs (2)
113private readonly Action _onStart; 115public FakeServer(Action onStart)
src\DataProtection\shared\test\ExceptionAssert2.cs (1)
18public static CryptographicException ThrowsCryptographicException(Action testCode)
Microsoft.AspNetCore.Diagnostics.Middleware (1)
Latency\CapturePipelineEntryStartupFilter.cs (1)
20/// <returns>A modified <see cref="Action"/>.</returns>
Microsoft.AspNetCore.HeaderPropagation.Tests (1)
HeaderPropagationMiddlewareTest.cs (1)
29public Action Assertion { get; set; }
Microsoft.AspNetCore.Hosting (2)
Startup\DelegateStartup.cs (2)
22/// <param name="configureApp">An <see cref="Action"/> for configuring the application.</param> 29/// Configures the <see cref="IApplicationBuilder"/> with the initialized <see cref="Action"/>.
Microsoft.AspNetCore.Hosting.Abstractions (6)
IStartupConfigureContainerFilter.cs (2)
14/// Extends the provided <paramref name="container"/> and returns a modified <see cref="Action"/> action of the same type. 17/// <returns>A modified <see cref="Action"/>.</returns>
IStartupConfigureServicesFilter.cs (2)
16/// Extends the provided <paramref name="next"/> and returns a modified <see cref="Action"/> action of the same type. 19/// <returns>A modified <see cref="Action"/>.</returns>
IStartupFilter.cs (2)
17/// Extends the provided <paramref name="next"/> and returns an <see cref="Action"/> of the same type. 20/// <returns>A modified <see cref="Action"/>.</returns>
Microsoft.AspNetCore.Hosting.Tests (23)
WebHostTests.cs (23)
492Action started = () => 496Action stopping = () => 501Action disposing = () => 581Action started = () => 586Action stopping = () => 591Action disposing = () => 634Action started = () => 639Action stopping = () => 644Action disposing = () => 775private readonly Action _verifyConfigureOrder; 776private readonly Action _verifyBuildBeforeOrder; 777private readonly Action _verifyBuildAfterOrder; 779public TestFilter(Action verifyConfigureOrder, Action verifyBuildBeforeOrder, Action verifyBuildAfterOrder) 1117Action started = () => 1123Action stopping = () => 1186private readonly Action _started; 1187private readonly Action _stopping; 1188private readonly Action _disposing; 1190public DelegateHostedService(Action started, Action stopping, Action disposing)
Microsoft.AspNetCore.Http.Abstractions.Tests (4)
UsePathBaseExtensionsTests.cs (2)
33private readonly Action _useCallback; 35public ApplicationBuilderWrapper(IApplicationBuilder applicationBuilder, Action useCallback)
UseWhenExtensionsTests.cs (2)
17Action nullPredicate = () => builder.UseWhen(null!, app => { }); 18Action nullConfiguration = () => builder.UseWhen(TruePredicate, null!);
Microsoft.AspNetCore.Http.Connections (2)
src\SignalR\common\Shared\AwaitableThreadPool.cs (2)
27public void OnCompleted(Action continuation) 32public void UnsafeOnCompleted(Action continuation)
Microsoft.AspNetCore.Http.Extensions (20)
src\Shared\ObjectMethodExecutor\AwaitableInfo.cs (2)
17private static readonly MethodInfo INotifyCompletion_OnCompleted = typeof(INotifyCompletion).GetMethod(nameof(INotifyCompletion.OnCompleted), Everything, new[] { typeof(Action) })!; 18private static readonly MethodInfo ICriticalNotifyCompletion_UnsafeOnCompleted = typeof(ICriticalNotifyCompletion).GetMethod(nameof(ICriticalNotifyCompletion.UnsafeOnCompleted), Everything, new[] { typeof(Action) })!;
src\Shared\ObjectMethodExecutor\ObjectMethodExecutor.cs (8)
26typeof(Action<object, Action>), // onCompletedMethod 27typeof(Action<object, Action>) // unsafeOnCompletedMethod 334var onCompletedParam2 = Expression.Parameter(typeof(Action), "continuation"); 335var onCompletedFunc = Expression.Lambda<Action<object, Action>>( 343Action<object, Action>? unsafeOnCompletedFunc = null; 350var unsafeOnCompletedParam2 = Expression.Parameter(typeof(Action), "continuation"); 351unsafeOnCompletedFunc = Expression.Lambda<Action<object, Action>>( 380Expression.Constant(unsafeOnCompletedFunc, typeof(Action<object, Action>)));
src\Shared\ObjectMethodExecutor\ObjectMethodExecutorAwaitable.cs (10)
22private readonly Action<object, Action> _onCompletedMethod; 23private readonly Action<object, Action> _unsafeOnCompletedMethod; 48Action<object, Action> onCompletedMethod, 49Action<object, Action> unsafeOnCompletedMethod) 70private readonly Action<object, Action> _onCompletedMethod; 71private readonly Action<object, Action> _unsafeOnCompletedMethod; 77Action<object, Action> onCompletedMethod, 78Action<object, Action> unsafeOnCompletedMethod) 91public void OnCompleted(Action continuation) 96public void UnsafeOnCompleted(Action continuation)
Microsoft.AspNetCore.Http.Extensions.Tests (4)
RequestDelegateFactoryTests.cs (4)
2381new object[] { (Action)VoidMethod }, 2548var @delegate = () => { }; 2607var @delegate = [Attribute1, Attribute2] () => { }; 2952var @delegate = void () => { };
Microsoft.AspNetCore.Http.Results.Tests (1)
ServerSentEventsResultTests.cs (1)
322private class MockHttpResponseBodyFeature(Action onDisableBuffering) : IHttpResponseBodyFeature
Microsoft.AspNetCore.InternalTesting (11)
AssemblyTestLog.cs (2)
343private readonly Action _action; 345public Disposable(Action action)
ExceptionAssertions.cs (9)
20public static TException Throws<TException>(Action testCode) 34public static TException Throws<TException>(Action testCode, string exceptionMessage) 82public static ArgumentException ThrowsArgument(Action testCode, string paramName, string exceptionMessage) 88Action testCode, 135public static ArgumentNullException ThrowsArgumentNull(Action testCode, string paramName) 152public static ArgumentException ThrowsArgumentNullOrEmpty(Action testCode, string paramName) 176public static ArgumentException ThrowsArgumentNullOrEmptyString(Action testCode, string paramName) 201public static ArgumentOutOfRangeException ThrowsArgumentOutOfRange(Action testCode, string paramName, string exceptionMessage, object actualValue = null) 223private static Exception RecordException(Action testCode)
Microsoft.AspNetCore.InternalTesting.Tests (2)
ExceptionAssertTest.cs (2)
16Action action = () => 30Action action = () =>
Microsoft.AspNetCore.JsonPatch (2)
Adapters\ObjectAdapter.cs (2)
19/// <param name="logErrorAction">The <see cref="Action"/> for logging <see cref="JsonPatchError"/>.</param> 31/// <param name="logErrorAction">The <see cref="Action"/> for logging <see cref="JsonPatchError"/>.</param>
Microsoft.AspNetCore.JsonPatch.SystemTextJson (2)
Adapters\ObjectAdapter.cs (2)
20/// <param name="logErrorAction">The <see cref="Action"/> for logging <see cref="JsonPatchError"/>.</param> 32/// <param name="logErrorAction">The <see cref="Action"/> for logging <see cref="JsonPatchError"/>.</param>
Microsoft.AspNetCore.Mvc.Core (28)
Controllers\IControllerActivatorProvider.cs (2)
19/// Creates an <see cref="Action"/> that releases a controller. 26/// Creates an <see cref="Action"/> that releases a controller.
DependencyInjection\MvcCoreMvcBuilderExtensions.cs (2)
42/// <param name="configure">An <see cref="Action"/> to configure the <see cref="JsonOptions"/>.</param> 59/// <param name="setupAction">An <see cref="Action"/> to configure the <see cref="FormatterMappings"/>.</param>
DependencyInjection\MvcCoreMvcCoreBuilderExtensions.cs (3)
43/// <param name="configure">An <see cref="Action"/> to configure the <see cref="JsonOptions"/>.</param> 71/// <param name="setupAction">An <see cref="Action"/> to configure the <see cref="FormatterMappings"/>.</param> 108/// <param name="setupAction">An <see cref="Action"/> to configure the <see cref="AuthorizationOptions"/>.</param>
Infrastructure\IActionDescriptorCollectionProvider.cs (1)
22/// using <see cref="ChangeToken.OnChange(System.Func{IChangeToken}, System.Action)"/>.
src\Shared\ObjectMethodExecutor\AwaitableInfo.cs (2)
17private static readonly MethodInfo INotifyCompletion_OnCompleted = typeof(INotifyCompletion).GetMethod(nameof(INotifyCompletion.OnCompleted), Everything, new[] { typeof(Action) })!; 18private static readonly MethodInfo ICriticalNotifyCompletion_UnsafeOnCompleted = typeof(ICriticalNotifyCompletion).GetMethod(nameof(ICriticalNotifyCompletion.UnsafeOnCompleted), Everything, new[] { typeof(Action) })!;
src\Shared\ObjectMethodExecutor\ObjectMethodExecutor.cs (8)
26typeof(Action<object, Action>), // onCompletedMethod 27typeof(Action<object, Action>) // unsafeOnCompletedMethod 334var onCompletedParam2 = Expression.Parameter(typeof(Action), "continuation"); 335var onCompletedFunc = Expression.Lambda<Action<object, Action>>( 343Action<object, Action>? unsafeOnCompletedFunc = null; 350var unsafeOnCompletedParam2 = Expression.Parameter(typeof(Action), "continuation"); 351unsafeOnCompletedFunc = Expression.Lambda<Action<object, Action>>( 380Expression.Constant(unsafeOnCompletedFunc, typeof(Action<object, Action>)));
src\Shared\ObjectMethodExecutor\ObjectMethodExecutorAwaitable.cs (10)
22private readonly Action<object, Action> _onCompletedMethod; 23private readonly Action<object, Action> _unsafeOnCompletedMethod; 48Action<object, Action> onCompletedMethod, 49Action<object, Action> unsafeOnCompletedMethod) 70private readonly Action<object, Action> _onCompletedMethod; 71private readonly Action<object, Action> _unsafeOnCompletedMethod; 77Action<object, Action> onCompletedMethod, 78Action<object, Action> unsafeOnCompletedMethod) 91public void OnCompleted(Action continuation) 96public void UnsafeOnCompleted(Action continuation)
Microsoft.AspNetCore.Mvc.IntegrationTests (1)
ValidationIntegrationTests.cs (1)
2564public Delegate Delegate { get; set; } = typeof(ModelWithNonNullableReferenceTypeProperties).GetMethod(nameof(SomeMethod))!.CreateDelegate<Action>();
Microsoft.AspNetCore.Mvc.Razor.Test (4)
TagHelpers\TagHelperComponentTagHelperTest.cs (4)
323private readonly Action _initCallback; 324private readonly Action _processAsyncCallback; 327public CallbackTagHelperComponent(int order, Action initCallback, Action processAsyncCallback)
Microsoft.AspNetCore.Mvc.RazorPages (8)
ApplicationModels\PageConventionCollection.cs (8)
57/// <param name="action">The <see cref="Action"/>.</param> 82/// <param name="action">The <see cref="Action"/>.</param> 103/// <param name="action">The <see cref="Action"/>.</param> 126/// <param name="action">The <see cref="Action"/>.</param> 147/// <param name="action">The <see cref="Action"/>.</param> 170/// <param name="action">The <see cref="Action"/>.</param> 188/// <param name="action">The <see cref="Action"/>.</param> 211/// <param name="action">The <see cref="Action"/>.</param>
Microsoft.AspNetCore.Mvc.TagHelpers.Test (1)
CacheTagHelperTest.cs (1)
984public Action DisposeCallback { get; set; }
Microsoft.AspNetCore.OpenApi (20)
src\Shared\ObjectMethodExecutor\AwaitableInfo.cs (2)
17private static readonly MethodInfo INotifyCompletion_OnCompleted = typeof(INotifyCompletion).GetMethod(nameof(INotifyCompletion.OnCompleted), Everything, new[] { typeof(Action) })!; 18private static readonly MethodInfo ICriticalNotifyCompletion_UnsafeOnCompleted = typeof(ICriticalNotifyCompletion).GetMethod(nameof(ICriticalNotifyCompletion.UnsafeOnCompleted), Everything, new[] { typeof(Action) })!;
src\Shared\ObjectMethodExecutor\ObjectMethodExecutor.cs (8)
26typeof(Action<object, Action>), // onCompletedMethod 27typeof(Action<object, Action>) // unsafeOnCompletedMethod 334var onCompletedParam2 = Expression.Parameter(typeof(Action), "continuation"); 335var onCompletedFunc = Expression.Lambda<Action<object, Action>>( 343Action<object, Action>? unsafeOnCompletedFunc = null; 350var unsafeOnCompletedParam2 = Expression.Parameter(typeof(Action), "continuation"); 351unsafeOnCompletedFunc = Expression.Lambda<Action<object, Action>>( 380Expression.Constant(unsafeOnCompletedFunc, typeof(Action<object, Action>)));
src\Shared\ObjectMethodExecutor\ObjectMethodExecutorAwaitable.cs (10)
22private readonly Action<object, Action> _onCompletedMethod; 23private readonly Action<object, Action> _unsafeOnCompletedMethod; 48Action<object, Action> onCompletedMethod, 49Action<object, Action> unsafeOnCompletedMethod) 70private readonly Action<object, Action> _onCompletedMethod; 71private readonly Action<object, Action> _unsafeOnCompletedMethod; 77Action<object, Action> onCompletedMethod, 78Action<object, Action> unsafeOnCompletedMethod) 91public void OnCompleted(Action continuation) 96public void UnsafeOnCompleted(Action continuation)
Microsoft.AspNetCore.OutputCaching (2)
Streams\OutputCacheStream.cs (2)
14private readonly Action _startResponseCallback; 16internal OutputCacheStream(Stream innerStream, long maxBufferSize, int segmentSize, Action startResponseCallback)
Microsoft.AspNetCore.OutputCaching.Microbenchmarks (1)
EndToEndBenchmarks.cs (1)
27private static readonly Action _noop = () => { };
Microsoft.AspNetCore.Razor.Runtime.Test (4)
Runtime\TagHelpers\TagHelperRunnerTest.cs (4)
267private readonly Action _initCallback; 268private readonly Action _processAsyncCallback; 270public CallbackTagHelper(Action initCallback, Action processAsyncCallback)
Microsoft.AspNetCore.ResponseCaching (2)
Streams\ResponseCachingStream.cs (2)
14private readonly Action _startResponseCallback; 16internal ResponseCachingStream(Stream innerStream, long maxBufferSize, int segmentSize, Action startResponseCallback)
Microsoft.AspNetCore.Routing.Tests (1)
Builder\RouteHandlerEndpointRouteBuilderExtensionsTest.cs (1)
74var endpointBuilder = builder.MapMethods("/", new[] { "METHOD" }, (Action)TestAction);
Microsoft.AspNetCore.Server.IntegrationTesting (1)
Common\RetryHelper.cs (1)
70Action retryBlock,
Microsoft.AspNetCore.Server.Kestrel.Core (9)
Internal\Infrastructure\Disposable.cs (2)
11private Action? _dispose; 14public Disposable(Action dispose)
Internal\Infrastructure\StreamCloseAwaitable.cs (4)
11private static readonly Action _callbackCompleted = () => { }; 15private Action? _callback = _callbackCompleted; 27public void OnCompleted(Action continuation) 36public void UnsafeOnCompleted(Action continuation)
KestrelConfigurationLoader.cs (3)
75private IList<Action> EndpointsToAdd { get; } = new List<Action>(); 312foreach (var action in EndpointsToAdd)
Microsoft.AspNetCore.Server.Kestrel.Core.Tests (1)
HttpRequestHeadersTests.cs (1)
562Assert.Throws<InvalidOperationException>((Action)(() =>
Microsoft.AspNetCore.Server.Kestrel.Tests (2)
KestrelConfigurationLoaderTests.cs (2)
1856Action load = loadInternal ? serverOptions.ConfigurationLoader.LoadInternal : serverOptions.ConfigurationLoader.Load; 1924Action load = loadInternal ? serverOptions.ConfigurationLoader.LoadInternal : serverOptions.ConfigurationLoader.Load;
Microsoft.AspNetCore.Shared.Tests (29)
ObjectMethodExecutorTest.cs (6)
590private List<Action> _onCompletedCallbacks = new List<Action>(); 608foreach (var callback in _onCompletedCallbacks) 630public void OnCompleted(Action continuation) 679public void OnCompleted(Action continuation) 686public void UnsafeOnCompleted(Action continuation)
SingleThreadedSynchronizationContext.cs (1)
26public static void Run(Action action)
src\Shared\ObjectMethodExecutor\AwaitableInfo.cs (2)
17private static readonly MethodInfo INotifyCompletion_OnCompleted = typeof(INotifyCompletion).GetMethod(nameof(INotifyCompletion.OnCompleted), Everything, new[] { typeof(Action) })!; 18private static readonly MethodInfo ICriticalNotifyCompletion_UnsafeOnCompleted = typeof(ICriticalNotifyCompletion).GetMethod(nameof(ICriticalNotifyCompletion.UnsafeOnCompleted), Everything, new[] { typeof(Action) })!;
src\Shared\ObjectMethodExecutor\ObjectMethodExecutor.cs (8)
26typeof(Action<object, Action>), // onCompletedMethod 27typeof(Action<object, Action>) // unsafeOnCompletedMethod 334var onCompletedParam2 = Expression.Parameter(typeof(Action), "continuation"); 335var onCompletedFunc = Expression.Lambda<Action<object, Action>>( 343Action<object, Action>? unsafeOnCompletedFunc = null; 350var unsafeOnCompletedParam2 = Expression.Parameter(typeof(Action), "continuation"); 351unsafeOnCompletedFunc = Expression.Lambda<Action<object, Action>>( 380Expression.Constant(unsafeOnCompletedFunc, typeof(Action<object, Action>)));
src\Shared\ObjectMethodExecutor\ObjectMethodExecutorAwaitable.cs (10)
22private readonly Action<object, Action> _onCompletedMethod; 23private readonly Action<object, Action> _unsafeOnCompletedMethod; 48Action<object, Action> onCompletedMethod, 49Action<object, Action> unsafeOnCompletedMethod) 70private readonly Action<object, Action> _onCompletedMethod; 71private readonly Action<object, Action> _unsafeOnCompletedMethod; 77Action<object, Action> onCompletedMethod, 78Action<object, Action> unsafeOnCompletedMethod) 91public void OnCompleted(Action continuation) 96public void UnsafeOnCompleted(Action continuation)
StackTraceHelperTest.cs (2)
234var action = (Action)Expression.Lambda(
Microsoft.AspNetCore.SignalR.Client.Core (8)
HubConnectionExtensions.cs (1)
32public static IDisposable On(this HubConnection hubConnection, string methodName, Action handler)
src\SignalR\common\Shared\AwaitableThreadPool.cs (2)
27public void OnCompleted(Action continuation) 32public void UnsafeOnCompleted(Action continuation)
src\SignalR\common\Shared\TimerAwaitable.cs (5)
16private Action? _callback; 17private static readonly Action _callbackCompleted = () => { }; 76var continuation = Interlocked.Exchange(ref _callback, _callbackCompleted); 80public void OnCompleted(Action continuation) 89public void UnsafeOnCompleted(Action continuation)
Microsoft.AspNetCore.SignalR.Core (20)
src\Shared\ObjectMethodExecutor\AwaitableInfo.cs (2)
17private static readonly MethodInfo INotifyCompletion_OnCompleted = typeof(INotifyCompletion).GetMethod(nameof(INotifyCompletion.OnCompleted), Everything, new[] { typeof(Action) })!; 18private static readonly MethodInfo ICriticalNotifyCompletion_UnsafeOnCompleted = typeof(ICriticalNotifyCompletion).GetMethod(nameof(ICriticalNotifyCompletion.UnsafeOnCompleted), Everything, new[] { typeof(Action) })!;
src\Shared\ObjectMethodExecutor\ObjectMethodExecutor.cs (8)
26typeof(Action<object, Action>), // onCompletedMethod 27typeof(Action<object, Action>) // unsafeOnCompletedMethod 334var onCompletedParam2 = Expression.Parameter(typeof(Action), "continuation"); 335var onCompletedFunc = Expression.Lambda<Action<object, Action>>( 343Action<object, Action>? unsafeOnCompletedFunc = null; 350var unsafeOnCompletedParam2 = Expression.Parameter(typeof(Action), "continuation"); 351unsafeOnCompletedFunc = Expression.Lambda<Action<object, Action>>( 380Expression.Constant(unsafeOnCompletedFunc, typeof(Action<object, Action>)));
src\Shared\ObjectMethodExecutor\ObjectMethodExecutorAwaitable.cs (10)
22private readonly Action<object, Action> _onCompletedMethod; 23private readonly Action<object, Action> _unsafeOnCompletedMethod; 48Action<object, Action> onCompletedMethod, 49Action<object, Action> unsafeOnCompletedMethod) 70private readonly Action<object, Action> _onCompletedMethod; 71private readonly Action<object, Action> _unsafeOnCompletedMethod; 77Action<object, Action> onCompletedMethod, 78Action<object, Action> unsafeOnCompletedMethod) 91public void OnCompleted(Action continuation) 96public void UnsafeOnCompleted(Action continuation)
Microsoft.AspNetCore.SignalR.Tests.Utils (2)
DummyHubProtocol.cs (2)
12private readonly Action _onWrite; 23public DummyHubProtocol(string name, Action onWrite = null)
Microsoft.AspNetCore.SpaServices.Extensions (1)
Util\EventedStreamReader.cs (1)
41void ResolveIfStillPending(Action applyResolution)
Microsoft.AspNetCore.TestHost (8)
ApplicationWrapper.cs (2)
21private readonly Action _preProcessRequestAsync; 23public ApplicationWrapper(IHttpApplication<TContext> application, Action preProcessRequestAsync)
ResponseBodyReaderStream.cs (4)
20private readonly Action _abortRequest; 21private readonly Action _readComplete; 24internal ResponseBodyReaderStream(Pipe pipe, Action abortRequest, Action readComplete)
WebHostBuilderExtensions.cs (2)
77/// <param name="servicesConfiguration">An <see cref="Action"/> that registers services onto the <see cref="IServiceCollection"/>.</param> 105/// <param name="servicesConfiguration">An <see cref="Action"/> that registers services onto the <typeparamref name="TContainer"/>.</param>
Microsoft.Build.Framework (1)
FileClassifier.cs (1)
44public event Action? OnImmutablePathsInitialized;
Microsoft.Cci.Extensions (11)
src\Common\Internal\DisposeAction.cs (2)
9private Action _action; 10public DisposeAction(Action action)
Writers\CSharp\CSDeclarationWriter.Generics.cs (2)
44Action[] constraints = GetConstraints(param, methodNullableContextValue).ToArray(); 58private IEnumerable<Action> GetConstraints(IGenericParameter parameter, byte? methodNullableContextValue)
Writers\CSharp\CSDeclarationWriter.Types.cs (1)
117private IEnumerable<Action> GetInterfaceWriterActions(ITypeReference type, IEnumerable<ITypeReference> interfaces)
Writers\Syntax\HtmlSyntaxWriter.cs (4)
18private Action _writeColor; 19private Action _writeBackground; 99Action write = _writeColor; 106Action write = _writeBackground;
Writers\Syntax\ISyntaxWriter.cs (2)
110private readonly Action _endBlock; 112public Block(Action endBlock)
Microsoft.CodeAnalysis (15)
InternalUtilities\UICultureUtilities.cs (2)
114public static Action WithCurrentUICulture(Action action)
MetadataReference\ModuleMetadata.cs (8)
28private Action? _onDispose; 32private ModuleMetadata(PEReader peReader, Action? onDispose) 42Action? onDispose, 87Action onDispose) 98Action? onDispose) 130private static unsafe ModuleMetadata CreateFromImage(byte* peImage, int size, Action? onDispose) 232Action? onDispose = options.HasFlag(PEStreamOptions.LeaveOpen) 296var onDispose = Interlocked.Exchange(ref _onDispose, null);
src\Dependencies\PooledObjects\PooledDelegates.cs (5)
37/// Gets an <see cref="Action"/> delegate, which calls <paramref name="unboundAction"/> with the specified 65public static Releaser GetPooledAction<TArg>(Action<TArg> unboundAction, TArg argument, out Action boundAction) 66=> GetPooledDelegate<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action>(unboundAction, argument, out boundAction); 384: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action> 386protected override Action Bind()
Microsoft.CodeAnalysis.Analyzers (16)
MetaAnalyzers\RegisterActionAnalyzer.cs (1)
337if (type == null || type.Name.Equals(nameof(Action), StringComparison.Ordinal))
src\Dependencies\PooledObjects\PooledDelegates.cs (5)
37/// Gets an <see cref="Action"/> delegate, which calls <paramref name="unboundAction"/> with the specified 65public static Releaser GetPooledAction<TArg>(Action<TArg> unboundAction, TArg argument, out Action boundAction) 66=> GetPooledDelegate<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action>(unboundAction, argument, out boundAction); 384: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action> 386protected override Action Bind()
src\Dependencies\Threading\ConfiguredYieldAwaitable.cs (3)
36static continuation => ((Action)continuation!)(); 52public void OnCompleted(Action continuation) 66public void UnsafeOnCompleted(Action continuation)
src\Dependencies\Threading\TaskExtensions.cs (2)
104public void OnCompleted(Action continuation) 114public void UnsafeOnCompleted(Action continuation)
src\Dependencies\Threading\ValueTaskExtensions.cs (4)
135public void OnCompleted(Action continuation) 145public void UnsafeOnCompleted(Action continuation) 235public void OnCompleted(Action continuation) 245public void UnsafeOnCompleted(Action continuation)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Extensions\Compilation\CompilationExtensions.cs (1)
136=> compilation.GetTypeByMetadataName(typeof(Action).FullName!);
Microsoft.CodeAnalysis.AnalyzerUtilities (15)
src\Dependencies\PooledObjects\PooledDelegates.cs (5)
37/// Gets an <see cref="Action"/> delegate, which calls <paramref name="unboundAction"/> with the specified 65public static Releaser GetPooledAction<TArg>(Action<TArg> unboundAction, TArg argument, out Action boundAction) 66=> GetPooledDelegate<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action>(unboundAction, argument, out boundAction); 384: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action> 386protected override Action Bind()
src\Dependencies\Threading\ConfiguredYieldAwaitable.cs (3)
36static continuation => ((Action)continuation!)(); 52public void OnCompleted(Action continuation) 66public void UnsafeOnCompleted(Action continuation)
src\Dependencies\Threading\TaskExtensions.cs (2)
104public void OnCompleted(Action continuation) 114public void UnsafeOnCompleted(Action continuation)
src\Dependencies\Threading\ValueTaskExtensions.cs (4)
135public void OnCompleted(Action continuation) 145public void UnsafeOnCompleted(Action continuation) 235public void OnCompleted(Action continuation) 245public void UnsafeOnCompleted(Action continuation)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Extensions\Compilation\CompilationExtensions.cs (1)
136=> compilation.GetTypeByMetadataName(typeof(Action).FullName!);
Microsoft.CodeAnalysis.BannedApiAnalyzers (15)
src\Dependencies\PooledObjects\PooledDelegates.cs (5)
37/// Gets an <see cref="Action"/> delegate, which calls <paramref name="unboundAction"/> with the specified 65public static Releaser GetPooledAction<TArg>(Action<TArg> unboundAction, TArg argument, out Action boundAction) 66=> GetPooledDelegate<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action>(unboundAction, argument, out boundAction); 384: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action> 386protected override Action Bind()
src\Dependencies\Threading\ConfiguredYieldAwaitable.cs (3)
36static continuation => ((Action)continuation!)(); 52public void OnCompleted(Action continuation) 66public void UnsafeOnCompleted(Action continuation)
src\Dependencies\Threading\TaskExtensions.cs (2)
104public void OnCompleted(Action continuation) 114public void UnsafeOnCompleted(Action continuation)
src\Dependencies\Threading\ValueTaskExtensions.cs (4)
135public void OnCompleted(Action continuation) 145public void UnsafeOnCompleted(Action continuation) 235public void OnCompleted(Action continuation) 245public void UnsafeOnCompleted(Action continuation)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Extensions\Compilation\CompilationExtensions.cs (1)
136=> compilation.GetTypeByMetadataName(typeof(Action).FullName!);
Microsoft.CodeAnalysis.CodeStyle (15)
src\Dependencies\PooledObjects\PooledDelegates.cs (5)
37/// Gets an <see cref="Action"/> delegate, which calls <paramref name="unboundAction"/> with the specified 65public static Releaser GetPooledAction<TArg>(Action<TArg> unboundAction, TArg argument, out Action boundAction) 66=> GetPooledDelegate<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action>(unboundAction, argument, out boundAction); 384: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action> 386protected override Action Bind()
src\Dependencies\Threading\ConfiguredYieldAwaitable.cs (3)
36static continuation => ((Action)continuation!)(); 52public void OnCompleted(Action continuation) 66public void UnsafeOnCompleted(Action continuation)
src\Dependencies\Threading\TaskExtensions.cs (2)
104public void OnCompleted(Action continuation) 114public void UnsafeOnCompleted(Action continuation)
src\Dependencies\Threading\ValueTaskExtensions.cs (4)
135public void OnCompleted(Action continuation) 145public void UnsafeOnCompleted(Action continuation) 235public void OnCompleted(Action continuation) 245public void UnsafeOnCompleted(Action continuation)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Extensions\Compilation\CompilationExtensions.cs (1)
136=> compilation.GetTypeByMetadataName(typeof(Action).FullName!);
Microsoft.CodeAnalysis.CodeStyle.Fixes (1)
src\Analyzers\Core\CodeFixes\GenerateParameterizedMember\AbstractGenerateMethodService.State.cs (1)
170var parameterNames = delegateInvokeMethod.ContainingType is { Name: nameof(Action) or nameof(Func<>), ContainingNamespace.Name: nameof(System) }
Microsoft.CodeAnalysis.Collections.Package (5)
src\Dependencies\PooledObjects\PooledDelegates.cs (5)
37/// Gets an <see cref="Action"/> delegate, which calls <paramref name="unboundAction"/> with the specified 65public static Releaser GetPooledAction<TArg>(Action<TArg> unboundAction, TArg argument, out Action boundAction) 66=> GetPooledDelegate<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action>(unboundAction, argument, out boundAction); 384: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action> 386protected override Action Bind()
Microsoft.CodeAnalysis.CSharp.CodeStyle (2)
src\Analyzers\CSharp\Analyzers\InvokeDelegateWithConditionalAccess\InvokeDelegateWithConditionalAccessAnalyzer.cs (2)
152if (invocationExpression.Expression is MemberAccessExpressionSyntax { Name: IdentifierNameSyntax { Identifier.ValueText: nameof(Action.Invoke) } } memberAccessExpression && 243Name: IdentifierNameSyntax { Identifier.ValueText: nameof(Action.Invoke) },
Microsoft.CodeAnalysis.CSharp.CodeStyle.Fixes (4)
src\Analyzers\CSharp\CodeFixes\InvokeDelegateWithConditionalAccess\InvokeDelegateWithConditionalAccessCodeFixProvider.cs (4)
88invocationExpression.Expression is MemberAccessExpressionSyntax { Name: IdentifierNameSyntax { Identifier.ValueText: nameof(Action.Invoke) } } memberAccessExpression 90: (invocationExpression.Expression, IdentifierName(nameof(Action.Invoke))); 131invocationExpression.Expression is MemberAccessExpressionSyntax { Name: IdentifierNameSyntax { Identifier.ValueText: nameof(Action.Invoke) } } memberAccessExpression 133: IdentifierName(nameof(Action.Invoke));
Microsoft.CodeAnalysis.CSharp.EditorFeatures (15)
AutomaticCompletion\AutomaticLineEnderCommandHandler.cs (1)
58protected override void NextAction(IEditorOperations editorOperation, Action nextAction)
CompleteStatement\CompleteStatementCommandHandler.cs (1)
73public void ExecuteCommand(TypeCharCommandArgs args, Action nextCommandHandler, CommandExecutionContext executionContext)
ConvertNamespace\ConvertNamespaceCommandHandler.cs (1)
63public void ExecuteCommand(TypeCharCommandArgs args, Action nextCommandHandler, CommandExecutionContext executionContext)
EventHookup\EventHookupCommandHandler_TabKeyCommand.cs (3)
50public void ExecuteCommand(TabKeyCommandArgs args, Action nextHandler, CommandExecutionContext context) 60private bool TryExecuteCommand(TabKeyCommandArgs args, Action nextHandler) 116Action nextHandler,
EventHookup\EventHookupCommandHandler_TypeCharCommand.cs (1)
22public void ExecuteCommand(TypeCharCommandArgs args, Action nextHandler, CommandExecutionContext context)
EventHookup\EventHookupSessionManager_EventHookupSession.cs (1)
39public event Action Dismissed = () => { };
FixInterpolatedVerbatimString\FixInterpolatedVerbatimStringCommandHandler.cs (1)
37public void ExecuteCommand(TypeCharCommandArgs args, Action nextCommandHandler, CommandExecutionContext executionContext)
RawStringLiteral\RawStringLiteralCommandHandler_TypeChar.cs (2)
25public void ExecuteCommand(TypeCharCommandArgs args, Action nextCommandHandler, CommandExecutionContext context) 31private bool ExecuteCommandWorker(TypeCharCommandArgs args, Action nextCommandHandler)
StringCopyPaste\StringCopyPasteCommandHandler.cs (1)
75public void ExecuteCommand(PasteCommandArgs args, Action nextCommandHandler, CommandExecutionContext executionContext)
StringCopyPaste\StringCopyPasteCommandHandler_CutCopy.cs (3)
31public void ExecuteCommand(CutCommandArgs args, Action nextCommandHandler, CommandExecutionContext executionContext) 34public void ExecuteCommand(CopyCommandArgs args, Action nextCommandHandler, CommandExecutionContext executionContext) 37private void ExecuteCutOrCopyCommand(ITextView textView, ITextBuffer subjectBuffer, Action nextCommandHandler, CommandExecutionContext executionContext)
Microsoft.CodeAnalysis.CSharp.EditorFeatures.UnitTests (6)
AutomaticCompletion\AutomaticLineEnderTests.cs (1)
3424protected override Action CreateNextHandler(EditorTestWorkspace workspace)
NavigateTo\NavigateToSearcherTests.cs (4)
510public Action? OnSearchCachedDocumentsAsyncCalled { get; set; } 511public Action? OnSearchDocumentsAsyncCalled { get; set; } 512public Action? OnSearchGeneratedDocumentsAsyncCalled { get; set; } 513public Action? OnSearchProjectsAsyncCalled { get; set; }
SplitStringLiteral\SplitStringLiteralCommandHandlerTests.cs (1)
38Action callback,
Microsoft.CodeAnalysis.CSharp.EndToEnd.UnitTests (1)
EndToEndTests.cs (1)
37private static void RunInThread(Action action, TimeSpan? timeout = null)
Microsoft.CodeAnalysis.CSharp.Features (6)
src\Analyzers\CSharp\Analyzers\InvokeDelegateWithConditionalAccess\InvokeDelegateWithConditionalAccessAnalyzer.cs (2)
152if (invocationExpression.Expression is MemberAccessExpressionSyntax { Name: IdentifierNameSyntax { Identifier.ValueText: nameof(Action.Invoke) } } memberAccessExpression && 243Name: IdentifierNameSyntax { Identifier.ValueText: nameof(Action.Invoke) },
src\Analyzers\CSharp\CodeFixes\InvokeDelegateWithConditionalAccess\InvokeDelegateWithConditionalAccessCodeFixProvider.cs (4)
88invocationExpression.Expression is MemberAccessExpressionSyntax { Name: IdentifierNameSyntax { Identifier.ValueText: nameof(Action.Invoke) } } memberAccessExpression 90: (invocationExpression.Expression, IdentifierName(nameof(Action.Invoke))); 131invocationExpression.Expression is MemberAccessExpressionSyntax { Name: IdentifierNameSyntax { Identifier.ValueText: nameof(Action.Invoke) } } memberAccessExpression 133: IdentifierName(nameof(Action.Invoke));
Microsoft.CodeAnalysis.CSharp.Symbol.UnitTests (4)
SymbolDisplay\SymbolDisplayTests.cs (2)
3122public event Action Event; 3130public event Action Event;
Symbols\Source\CompletionTests.cs (2)
113Action reader = () => 121Action writers = () =>
Microsoft.CodeAnalysis.Debugging.Package (5)
src\Dependencies\PooledObjects\PooledDelegates.cs (5)
37/// Gets an <see cref="Action"/> delegate, which calls <paramref name="unboundAction"/> with the specified 65public static Releaser GetPooledAction<TArg>(Action<TArg> unboundAction, TArg argument, out Action boundAction) 66=> GetPooledDelegate<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action>(unboundAction, argument, out boundAction); 384: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action> 386protected override Action Bind()
Microsoft.CodeAnalysis.EditorFeatures (53)
AddImports\AbstractAddImportsPasteCommandHandler.cs (1)
49public void ExecuteCommand(PasteCommandArgs args, Action nextCommandHandler, CommandExecutionContext executionContext)
Adornments\GraphicsResult.cs (2)
14private Action? _dispose; 16public GraphicsResult(UIElement visualElement, Action? dispose)
AutomaticCompletion\AbstractAutomaticLineEnderCommandHandler.cs (2)
50protected abstract void NextAction(IEditorOperations editorOperation, Action nextAction); 75public void ExecuteCommand(AutomaticLineEnderCommandArgs args, Action nextHandler, CommandExecutionContext context)
DocumentationComments\AbstractDocumentationCommentCommandHandler.cs (3)
118public void ExecuteCommand(TypeCharCommandArgs args, Action nextHandler, CommandExecutionContext context) 231public void ExecuteCommand(OpenLineAboveCommandArgs args, Action nextHandler, CommandExecutionContext context) 267public void ExecuteCommand(OpenLineBelowCommandArgs args, Action nextHandler, CommandExecutionContext context)
DocumentationComments\AbstractXmlTagCompletionCommandHandler.cs (1)
48public void ExecuteCommand(TypeCharCommandArgs args, Action nextHandler, CommandExecutionContext context)
EditAndContinue\ActiveStatementTrackingService.cs (1)
67public event Action? TrackingChanged;
EditAndContinue\IActiveStatementTrackingService.cs (1)
23event Action TrackingChanged;
Formatting\FormatCommandHandler.cs (1)
102public void ExecuteReturnOrTypeCommand(EditorCommandArgs args, Action nextHandler, CancellationToken cancellationToken)
Formatting\FormatCommandHandler.Paste.cs (1)
22public void ExecuteCommand(PasteCommandArgs args, Action nextHandler, CommandExecutionContext context)
Formatting\FormatCommandHandler.ReturnKey.cs (1)
16public void ExecuteCommand(ReturnKeyCommandArgs args, Action nextHandler, CommandExecutionContext context)
Formatting\FormatCommandHandler.TypeChar.cs (1)
16public void ExecuteCommand(TypeCharCommandArgs args, Action nextHandler, CommandExecutionContext context)
InlineHints\IInlineHintKeyProcessor.cs (1)
20event Action StateChanged;
InlineHints\InlineHintsKeyProcessorProvider.cs (1)
57public event Action? StateChanged;
InlineRename\CommandHandlers\AbstractRenameCommandHandler.cs (1)
42private void HandlePossibleTypingCommand<TArgs>(TArgs args, Action nextHandler, IUIThreadOperationContext operationContext, Action<InlineRenameSession, IUIThreadOperationContext, SnapshotSpan> actionIfInsideActiveSpan)
InlineRename\CommandHandlers\AbstractRenameCommandHandler_BackspaceDeleteHandler.cs (2)
22public void ExecuteCommand(BackspaceKeyCommandArgs args, Action nextHandler, CommandExecutionContext context) 34public void ExecuteCommand(DeleteKeyCommandArgs args, Action nextHandler, CommandExecutionContext context)
InlineRename\CommandHandlers\AbstractRenameCommandHandler_CutPasteHandler.cs (2)
17public void ExecuteCommand(CutCommandArgs args, Action nextHandler, CommandExecutionContext context) 28public void ExecuteCommand(PasteCommandArgs args, Action nextHandler, CommandExecutionContext context)
InlineRename\CommandHandlers\AbstractRenameCommandHandler_OpenLineAboveHandler.cs (1)
16public void ExecuteCommand(OpenLineAboveCommandArgs args, Action nextHandler, CommandExecutionContext context)
InlineRename\CommandHandlers\AbstractRenameCommandHandler_OpenLineBelowHandler.cs (1)
16public void ExecuteCommand(OpenLineBelowCommandArgs args, Action nextHandler, CommandExecutionContext context)
InlineRename\CommandHandlers\AbstractRenameCommandHandler_TypeCharHandler.cs (1)
20public void ExecuteCommand(TypeCharCommandArgs args, Action nextHandler, CommandExecutionContext context)
InlineRename\IInlineRenameUndoManager.cs (1)
23void CreateConflictResolutionUndoTransaction(ITextBuffer subjectBuffer, Action applyEdit);
InlineRename\InlineRenameSession.cs (2)
452Action propagateEditAction = delegate 658Action finalCommitAction = null)
InlineRename\InlineRenameSession.OpenTextBufferManager.cs (1)
158public event Action SpansChanged;
InlineRename\UndoManagerServiceFactory.cs (1)
58public void CreateConflictResolutionUndoTransaction(ITextBuffer subjectBuffer, Action applyEdit)
IntelliSense\NavigationActionFactory.cs (1)
28public Action CreateNavigationAction(string navigationTarget)
IntelliSense\QuickInfo\QuickInfoHyperLink.cs (2)
23public Action NavigationAction { get; } 50public static Action CreateNavigationAction(Uri uri)
Interactive\InteractiveCommandHandler.cs (1)
85Action action = null;
Lightup\LightupHelpers.cs (1)
100/// Generates a compiled accessor method for a method with a signature compatible with <see cref="Action"/> which
NavigationBar\NavigationBarController.cs (1)
62private readonly Action _onVisibilityChanged;
PasteTracking\PasteTrackingPasteCommandHandler.cs (1)
38public void ExecuteCommand(PasteCommandArgs args, Action nextCommandHandler, CommandExecutionContext executionContext)
RenameTracking\RenameTrackingTaggerProvider.StateMachine.cs (1)
53public event Action TrackingSessionUpdated = delegate { };
SignatureHelp\Controller_InvokeSignatureHelp.cs (1)
23void IChainedCommandHandler<InvokeSignatureHelpCommandArgs>.ExecuteCommand(InvokeSignatureHelpCommandArgs args, Action nextHandler, CommandExecutionContext context)
SignatureHelp\Controller_TypeChar.cs (1)
28void IChainedCommandHandler<TypeCharCommandArgs>.ExecuteCommand(TypeCharCommandArgs args, Action nextHandler, CommandExecutionContext context)
SignatureHelp\SignatureHelpBeforeCompletionCommandHandler.cs (3)
81Action nextHandler, 102void IChainedCommandHandler<TypeCharCommandArgs>.ExecuteCommand(TypeCharCommandArgs args, Action nextHandler, CommandExecutionContext context) 114void IChainedCommandHandler<InvokeSignatureHelpCommandArgs>.ExecuteCommand(InvokeSignatureHelpCommandArgs args, Action nextHandler, CommandExecutionContext context)
Tagging\AbstractAsynchronousTaggerProvider.TagSource.cs (1)
110private readonly Action _onVisibilityChanged;
Workspaces\AbstractTextBufferVisibilityTracker.cs (6)
90public void RegisterForVisibilityChanges(ITextBuffer subjectBuffer, Action callback) 102public void UnregisterForVisibilityChanges(ITextBuffer subjectBuffer, Action callback) 146public ImmutableHashSet<Action> Callbacks { get; private set; } = []; 172public void AddCallback(Action callback) 178public void RemoveCallback(Action callback) 218foreach (var callback in Callbacks)
Workspaces\ITextBufferVisibilityTracker.cs (3)
31void RegisterForVisibilityChanges(ITextBuffer subjectBuffer, Action callback); 36void UnregisterForVisibilityChanges(ITextBuffer subjectBuffer, Action callback); 94var callback = void () => visibilityChangedTaskSource.TrySetResult(true);
Microsoft.CodeAnalysis.EditorFeatures.Test.Utilities (60)
AbstractCommandHandlerTestState.cs (47)
256public void SendBackspace(Action<BackspaceKeyCommandArgs, Action, CommandExecutionContext> commandHandler, Action nextHandler) 259public void SendDelete(Action<DeleteKeyCommandArgs, Action, CommandExecutionContext> commandHandler, Action nextHandler) 262public void SendWordDeleteToStart(Action<WordDeleteToStartCommandArgs, Action, CommandExecutionContext> commandHandler, Action nextHandler) 265public void SendEscape(Action<EscapeKeyCommandArgs, Action, CommandExecutionContext> commandHandler, Action nextHandler) 271public void SendUpKey(Action<UpKeyCommandArgs, Action, CommandExecutionContext> commandHandler, Action nextHandler) 274public void SendDownKey(Action<DownKeyCommandArgs, Action, CommandExecutionContext> commandHandler, Action nextHandler) 277public void SendTab(Action<TabKeyCommandArgs, Action, CommandExecutionContext> commandHandler, Action nextHandler) 283public void SendBackTab(Action<BackTabKeyCommandArgs, Action, CommandExecutionContext> commandHandler, Action nextHandler) 289public void SendReturn(Action<ReturnKeyCommandArgs, Action, CommandExecutionContext> commandHandler, Action nextHandler) 295public void SendPageUp(Action<PageUpKeyCommandArgs, Action, CommandExecutionContext> commandHandler, Action nextHandler) 298public void SendPageDown(Action<PageDownKeyCommandArgs, Action, CommandExecutionContext> commandHandler, Action nextHandler) 301public void SendCopy(Action<CopyCommandArgs, Action, CommandExecutionContext> commandHandler, Action nextHandler) 304public void SendCut(Action<CutCommandArgs, Action, CommandExecutionContext> commandHandler, Action nextHandler) 307public void SendPaste(Action<PasteCommandArgs, Action, CommandExecutionContext> commandHandler, Action nextHandler) 310public void SendInvokeCompletionList(Action<InvokeCompletionListCommandArgs, Action, CommandExecutionContext> commandHandler, Action nextHandler) 313public void SendCommitUniqueCompletionListItem(Action<CommitUniqueCompletionListItemCommandArgs, Action, CommandExecutionContext> commandHandler, Action nextHandler) 316public void SendInsertSnippetCommand(Action<InsertSnippetCommandArgs, Action, CommandExecutionContext> commandHandler, Action nextHandler) 322public void SendSurroundWithCommand(Action<SurroundWithCommandArgs, Action, CommandExecutionContext> commandHandler, Action nextHandler) 328public void SendInvokeSignatureHelp(Action<InvokeSignatureHelpCommandArgs, Action, CommandExecutionContext> commandHandler, Action nextHandler) 331public void SendTypeChar(char typeChar, Action<TypeCharCommandArgs, Action, CommandExecutionContext> commandHandler, Action nextHandler) 334public void SendTypeChars(string typeChars, Action<TypeCharCommandArgs, Action, CommandExecutionContext> commandHandler) 343public void SendSave(Action<SaveCommandArgs, Action, CommandExecutionContext> commandHandler, Action nextHandler) 346public void SendSelectAll(Action<SelectAllCommandArgs, Action, CommandExecutionContext> commandHandler, Action nextHandler) 349public void SendToggleCompletionMode(Action<ToggleCompletionModeCommandArgs, Action, CommandExecutionContext> commandHandler, Action nextHandler)
AbstractTypingCommandHandlerTest.cs (2)
40var nextHandler = CreateInsertTextHandler(view, insertionText); 61private static Action CreateInsertTextHandler(ITextView textView, string text)
Async\WaitHelper.cs (1)
17Action action = delegate { };
AutomaticCompletion\AbstractAutomaticLineEnderTests.cs (2)
26protected abstract Action CreateNextHandler(EditorTestWorkspace workspace); 85var nextHandler = assertNextHandlerInvoked ? () => nextHandlerInvoked = true : CreateNextHandler(workspace);
CompleteStatement\AbstractCompleteStatementTests.cs (2)
81var nextHandler = CreateInsertTextHandler(view, Semicolon.ToString()); 86private static Action CreateInsertTextHandler(ITextView textView, string text)
DocumentationComments\AbstractDocumentationCommentTests.cs (4)
39var nextHandler = CreateInsertTextHandler(view, DocumentationCommentCharacter.ToString()); 54var nextHandler = CreateInsertTextHandler(view, "\r\n"); 68Action nextHandler = delegate { }; 113private static Action CreateInsertTextHandler(ITextView textView, string text)
DocumentationComments\AbstractXmlTagCompletionTests.cs (2)
37var nextHandler = CreateInsertTextHandler(view, typeChar.ToString()); 49private static Action CreateInsertTextHandler(ITextView textView, string text)
Microsoft.CodeAnalysis.EditorFeatures.UnitTests (1)
CodeGeneration\CodeGenerationTests.cs (1)
385type ??= typeof(Action);
Microsoft.CodeAnalysis.ExpressionEvaluator.ResultProvider.Utilities (4)
Debugger\Engine\DkmWorkList.cs (4)
23private readonly Queue<Action> _workList; 30_workList = new Queue<Action>(1); 36internal void AddWork(Action item) 53var item = _workList.Dequeue();
Microsoft.CodeAnalysis.Extensions.Package (6)
Compilation\CompilationExtensions.cs (1)
136=> compilation.GetTypeByMetadataName(typeof(Action).FullName!);
src\Dependencies\PooledObjects\PooledDelegates.cs (5)
37/// Gets an <see cref="Action"/> delegate, which calls <paramref name="unboundAction"/> with the specified 65public static Releaser GetPooledAction<TArg>(Action<TArg> unboundAction, TArg argument, out Action boundAction) 66=> GetPooledDelegate<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action>(unboundAction, argument, out boundAction); 384: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action> 386protected override Action Bind()
Microsoft.CodeAnalysis.ExternalAccess.Apex (2)
ApexAsynchronousOperationListenerProviderAccessor.cs (1)
31public Task WaitAllAsync(string[]? featureNames = null, Action? eventProcessingAction = null, TimeSpan? timeout = null)
IApexAsynchronousOperationListenerProviderAccessor.cs (1)
14Task WaitAllAsync(string[] featureNames = null, Action eventProcessingAction = null, TimeSpan? timeout = null);
Microsoft.CodeAnalysis.Features (11)
Diagnostics\IDiagnosticsRefresher.cs (2)
17event Action? WorkspaceRefreshRequested; 43public event Action? WorkspaceRefreshRequested;
Diagnostics\Service\DocumentAnalysisExecutor.cs (2)
33private readonly Action? _onAnalysisException; 46Action? onAnalysisException = null)
QuickInfo\Presentation\INavigationActionFactory.cs (1)
11Action CreateNavigationAction(string navigationTarget);
QuickInfo\Presentation\QuickInfoClassifiedTextRun.cs (2)
12Action? navigationAction = null, 24public Action? NavigationAction { get; } = navigationAction;
RemoveUnusedVariable\AbstractRemoveUnusedVariableCodeFixProvider.cs (2)
66var actionsToPerform = new List<(int, Action)>(); 77(int, Action) pair = (token.Parent.SpanStart,
Shared\Utilities\IUIContextActivationService.cs (1)
14IDisposable ExecuteWhenActivated(Guid uiContext, Action action);
src\Analyzers\Core\CodeFixes\GenerateParameterizedMember\AbstractGenerateMethodService.State.cs (1)
170var parameterNames = delegateInvokeMethod.ContainingType is { Name: nameof(Action) or nameof(Func<>), ContainingNamespace.Name: nameof(System) }
Microsoft.CodeAnalysis.Features.Test.Utilities (3)
EditAndContinue\MockEditAndContinueService.cs (3)
25public Action? EndDebuggingSessionImpl; 28public Action? CommitSolutionUpdateImpl; 30public Action? DiscardSolutionUpdateImpl;
Microsoft.CodeAnalysis.Features.UnitTests (1)
FindUsages\DefinitionItemFactoryTests.cs (1)
111void verify(Action assert)
Microsoft.CodeAnalysis.InteractiveHost (14)
src\Dependencies\PooledObjects\PooledDelegates.cs (5)
37/// Gets an <see cref="Action"/> delegate, which calls <paramref name="unboundAction"/> with the specified 65public static Releaser GetPooledAction<TArg>(Action<TArg> unboundAction, TArg argument, out Action boundAction) 66=> GetPooledDelegate<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action>(unboundAction, argument, out boundAction); 384: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action> 386protected override Action Bind()
src\Dependencies\Threading\ConfiguredYieldAwaitable.cs (3)
36static continuation => ((Action)continuation!)(); 52public void OnCompleted(Action continuation) 66public void UnsafeOnCompleted(Action continuation)
src\Dependencies\Threading\TaskExtensions.cs (2)
104public void OnCompleted(Action continuation) 114public void UnsafeOnCompleted(Action continuation)
src\Dependencies\Threading\ValueTaskExtensions.cs (4)
135public void OnCompleted(Action continuation) 145public void UnsafeOnCompleted(Action continuation) 235public void OnCompleted(Action continuation) 245public void UnsafeOnCompleted(Action continuation)
Microsoft.CodeAnalysis.LanguageServer (1)
HostWorkspace\WorkspaceProject.cs (1)
218private async Task RunAndReportNFWAsync(Action action, CancellationToken cancellationToken)
Microsoft.CodeAnalysis.LanguageServer.Protocol (3)
Protocol\Internal\Text\ClassifiedTextElement.cs (1)
30public static ClassifiedTextElement CreateHyperlink(string text, string tooltip, Action navigationAction)
Protocol\Internal\Text\ClassifiedTextRun.cs (2)
17Action? navigationAction = null, 25public Action? NavigationAction { get; } = navigationAction;
Microsoft.CodeAnalysis.PerformanceSensitiveAnalyzers (15)
src\Dependencies\PooledObjects\PooledDelegates.cs (5)
37/// Gets an <see cref="Action"/> delegate, which calls <paramref name="unboundAction"/> with the specified 65public static Releaser GetPooledAction<TArg>(Action<TArg> unboundAction, TArg argument, out Action boundAction) 66=> GetPooledDelegate<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action>(unboundAction, argument, out boundAction); 384: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action> 386protected override Action Bind()
src\Dependencies\Threading\ConfiguredYieldAwaitable.cs (3)
36static continuation => ((Action)continuation!)(); 52public void OnCompleted(Action continuation) 66public void UnsafeOnCompleted(Action continuation)
src\Dependencies\Threading\TaskExtensions.cs (2)
104public void OnCompleted(Action continuation) 114public void UnsafeOnCompleted(Action continuation)
src\Dependencies\Threading\ValueTaskExtensions.cs (4)
135public void OnCompleted(Action continuation) 145public void UnsafeOnCompleted(Action continuation) 235public void OnCompleted(Action continuation) 245public void UnsafeOnCompleted(Action continuation)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Extensions\Compilation\CompilationExtensions.cs (1)
136=> compilation.GetTypeByMetadataName(typeof(Action).FullName!);
Microsoft.CodeAnalysis.PooledObjects.Package (5)
PooledDelegates.cs (5)
37/// Gets an <see cref="Action"/> delegate, which calls <paramref name="unboundAction"/> with the specified 65public static Releaser GetPooledAction<TArg>(Action<TArg> unboundAction, TArg argument, out Action boundAction) 66=> GetPooledDelegate<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action>(unboundAction, argument, out boundAction); 384: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action> 386protected override Action Bind()
Microsoft.CodeAnalysis.PublicApiAnalyzers (15)
src\Dependencies\PooledObjects\PooledDelegates.cs (5)
37/// Gets an <see cref="Action"/> delegate, which calls <paramref name="unboundAction"/> with the specified 65public static Releaser GetPooledAction<TArg>(Action<TArg> unboundAction, TArg argument, out Action boundAction) 66=> GetPooledDelegate<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action>(unboundAction, argument, out boundAction); 384: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action> 386protected override Action Bind()
src\Dependencies\Threading\ConfiguredYieldAwaitable.cs (3)
36static continuation => ((Action)continuation!)(); 52public void OnCompleted(Action continuation) 66public void UnsafeOnCompleted(Action continuation)
src\Dependencies\Threading\TaskExtensions.cs (2)
104public void OnCompleted(Action continuation) 114public void UnsafeOnCompleted(Action continuation)
src\Dependencies\Threading\ValueTaskExtensions.cs (4)
135public void OnCompleted(Action continuation) 145public void UnsafeOnCompleted(Action continuation) 235public void OnCompleted(Action continuation) 245public void UnsafeOnCompleted(Action continuation)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Extensions\Compilation\CompilationExtensions.cs (1)
136=> compilation.GetTypeByMetadataName(typeof(Action).FullName!);
Microsoft.CodeAnalysis.ResxSourceGenerator (15)
src\Dependencies\PooledObjects\PooledDelegates.cs (5)
37/// Gets an <see cref="Action"/> delegate, which calls <paramref name="unboundAction"/> with the specified 65public static Releaser GetPooledAction<TArg>(Action<TArg> unboundAction, TArg argument, out Action boundAction) 66=> GetPooledDelegate<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action>(unboundAction, argument, out boundAction); 384: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action> 386protected override Action Bind()
src\Dependencies\Threading\ConfiguredYieldAwaitable.cs (3)
36static continuation => ((Action)continuation!)(); 52public void OnCompleted(Action continuation) 66public void UnsafeOnCompleted(Action continuation)
src\Dependencies\Threading\TaskExtensions.cs (2)
104public void OnCompleted(Action continuation) 114public void UnsafeOnCompleted(Action continuation)
src\Dependencies\Threading\ValueTaskExtensions.cs (4)
135public void OnCompleted(Action continuation) 145public void UnsafeOnCompleted(Action continuation) 235public void OnCompleted(Action continuation) 245public void UnsafeOnCompleted(Action continuation)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Extensions\Compilation\CompilationExtensions.cs (1)
136=> compilation.GetTypeByMetadataName(typeof(Action).FullName!);
Microsoft.CodeAnalysis.Scripting.TestUtilities (3)
ObjectFormatterFixtures\MockDesktopTask.cs (2)
20private readonly Action m_action; 22public MockDesktopTask(Action action)
ScriptingTestHelpers.cs (1)
74internal static void AssertCompilationError(Action action, params DiagnosticDescription[] expectedDiagnostics)
Microsoft.CodeAnalysis.Test.Utilities (6)
Assert\AssertEx.cs (3)
963public static void Multiple(params Action[] assertions) 968/// <inheritdoc cref="Multiple(System.Action[])"/> 969public static void Multiple(bool includeStackTrace, params Action[] assertions)
Compilation\RuntimeUtilities.cs (1)
82public static (string Output, string ErrorOutput) CaptureOutput(Action action, IFormatProvider? formatProvider = null)
Mocks\TestStream.cs (2)
20private readonly Action _dispose; 31Action dispose = null)
Microsoft.CodeAnalysis.Threading.Package (14)
ConfiguredYieldAwaitable.cs (3)
36static continuation => ((Action)continuation!)(); 52public void OnCompleted(Action continuation) 66public void UnsafeOnCompleted(Action continuation)
src\Dependencies\PooledObjects\PooledDelegates.cs (5)
37/// Gets an <see cref="Action"/> delegate, which calls <paramref name="unboundAction"/> with the specified 65public static Releaser GetPooledAction<TArg>(Action<TArg> unboundAction, TArg argument, out Action boundAction) 66=> GetPooledDelegate<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action>(unboundAction, argument, out boundAction); 384: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action> 386protected override Action Bind()
TaskExtensions.cs (2)
104public void OnCompleted(Action continuation) 114public void UnsafeOnCompleted(Action continuation)
ValueTaskExtensions.cs (4)
135public void OnCompleted(Action continuation) 145public void UnsafeOnCompleted(Action continuation) 235public void OnCompleted(Action continuation) 245public void UnsafeOnCompleted(Action continuation)
Microsoft.CodeAnalysis.UnitTests (1)
Collections\TestExtensionsMethods.cs (1)
18internal static void ValidateDefaultThisBehavior(Action a)
Microsoft.CodeAnalysis.Workspaces (23)
ErrorReporting\InfoBarUI.cs (2)
14public readonly Action Action; 17public InfoBarUI(string title, UIKind kind, Action action, bool closeAfterAction = true)
ExtensionManager\IExtensionManagerExtensions.cs (1)
16public static void PerformAction(this IExtensionManager extensionManager, object extension, Action action)
Shared\TestHooks\AsynchronousOperationListenerProvider.cs (1)
115public async Task WaitAllAsync(Workspace? workspace, string[]? featureNames = null, Action? eventProcessingAction = null, TimeSpan? timeout = null)
Shared\Utilities\IOUtilities.cs (1)
16public static void PerformIO(Action action)
src\Dependencies\PooledObjects\PooledDelegates.cs (5)
37/// Gets an <see cref="Action"/> delegate, which calls <paramref name="unboundAction"/> with the specified 65public static Releaser GetPooledAction<TArg>(Action<TArg> unboundAction, TArg argument, out Action boundAction) 66=> GetPooledDelegate<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action>(unboundAction, argument, out boundAction); 384: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action> 386protected override Action Bind()
src\Dependencies\Threading\ConfiguredYieldAwaitable.cs (3)
36static continuation => ((Action)continuation!)(); 52public void OnCompleted(Action continuation) 66public void UnsafeOnCompleted(Action continuation)
src\Dependencies\Threading\TaskExtensions.cs (2)
104public void OnCompleted(Action continuation) 114public void UnsafeOnCompleted(Action continuation)
src\Dependencies\Threading\ValueTaskExtensions.cs (4)
135public void OnCompleted(Action continuation) 145public void UnsafeOnCompleted(Action continuation) 235public void OnCompleted(Action continuation) 245public void UnsafeOnCompleted(Action continuation)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Extensions\Compilation\CompilationExtensions.cs (1)
136=> compilation.GetTypeByMetadataName(typeof(Action).FullName!);
Storage\SQLite\v2\SQLitePersistentStorage.cs (1)
41private readonly Action _flushInMemoryDataToDisk;
Storage\SQLite\v2\SQLitePersistentStorage_Threading.cs (1)
59public Task PerformWriteAsync(Action action, CancellationToken cancellationToken)
Workspace\Workspace.cs (1)
597protected internal Task ScheduleTask(Action action, string? taskName = "Workspace.Task")
Microsoft.CodeAnalysis.Workspaces.MSBuild.BuildHost (7)
src\Compilers\Core\Portable\InternalUtilities\UICultureUtilities.cs (2)
114public static Action WithCurrentUICulture(Action action)
src\Dependencies\PooledObjects\PooledDelegates.cs (5)
37/// Gets an <see cref="Action"/> delegate, which calls <paramref name="unboundAction"/> with the specified 65public static Releaser GetPooledAction<TArg>(Action<TArg> unboundAction, TArg argument, out Action boundAction) 66=> GetPooledDelegate<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action>(unboundAction, argument, out boundAction); 384: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action> 386protected override Action Bind()
Microsoft.Data.Analysis (2)
DataFrameColumnCollection.cs (2)
16private readonly Action ColumnsChanged; 21internal DataFrameColumnCollection(IEnumerable<DataFrameColumn> columns, Action columnsChanged) : base()
Microsoft.DotNet.Build.Manifest.Tests (1)
BuildModelFactoryTests.cs (1)
71Action act = () =>
Microsoft.DotNet.Build.Tasks.Feed.Tests (8)
ArtifactUrlHelperTests.cs (2)
39Action act = () => helper.ConstructDownloadUrl(fileName); 71Action act = () => helper.ConstructDownloadUrl(fileName);
SetupTargetFeedConfigV3Tests.cs (3)
448Action shouldFail = () => new TargetFeedSpecification(new TargetFeedContentType[] { TargetFeedContentType.Package }, "FooFeed", AssetSelection.All); 451Action shouldPassShippingOnly = () => new TargetFeedSpecification(new TargetFeedContentType[] { TargetFeedContentType.Package }, "FooFeed", AssetSelection.ShippingOnly); 454Action shouldPassNonShippingOnly = () => new TargetFeedSpecification(new TargetFeedContentType[] { TargetFeedContentType.Package }, "FooFeed", AssetSelection.NonShippingOnly);
SetupTargetFeedConfigV4Tests.cs (3)
400Action shouldFail = () => new TargetFeedSpecification(new TargetFeedContentType[] { TargetFeedContentType.Package }, "FooFeed", AssetSelection.All); 403Action shouldPassShippingOnly = () => new TargetFeedSpecification(new TargetFeedContentType[] { TargetFeedContentType.Package }, "FooFeed", AssetSelection.ShippingOnly); 406Action shouldPassNonShippingOnly = () => new TargetFeedSpecification(new TargetFeedContentType[] { TargetFeedContentType.Package }, "FooFeed", AssetSelection.NonShippingOnly);
Microsoft.DotNet.Build.Tasks.Packaging.Tests (4)
NugetPropertyStringProviderTests.cs (4)
61Action act = () => NuspecPropertyStringProvider.GetNuspecPropertyDictionary(new[] { "abc" }); 68Action act = () => NuspecPropertyStringProvider.GetNuspecPropertyDictionary(new[] { "a= " }); 75Action act = () => NuspecPropertyStringProvider.GetNuspecPropertyDictionary(new[] { " = b" }); 82Action act = () => NuspecPropertyStringProvider.GetNuspecPropertyDictionary(new[] { " = " });
Microsoft.DotNet.MacOsPkg.Tests (1)
UnpackPackTests.cs (1)
169private static void ExecuteWithCleanup(Action action, List<string> cleanupPaths)
Microsoft.DotNet.NuGetRepack.Tests (3)
TestHelpers\AssertEx.cs (3)
343public static void ThrowsArgumentNull(string parameterName, Action del) 355public static void ThrowsArgumentException(string parameterName, Action del) 367public static T Throws<T>(Action del, bool allowDerived = false) where T : Exception
Microsoft.DotNet.RemoteExecutor (1)
RemoteExecutor.cs (1)
123public static RemoteInvokeHandle Invoke(Action method, RemoteInvokeOptions options = null)
Microsoft.DotNet.SignTool.Tests (2)
SignToolTests.cs (2)
3384Action shouldFail = () => StrongNameHelper.Sign(inputStream, GetResourcePath("OpenSignedCorrespondingKey.snk")); 3395Action shouldFail = () => StrongNameHelper.Sign(inputStream, GetResourcePath("OpenSignedCorrespondingKey.snk"));
Microsoft.DotNet.SwaggerGenerator.CodeGenerator (3)
Modeler\Disposable.cs (3)
10private readonly Action _onDispose; 12private Disposable(Action onDispose) 22public static IDisposable Create(Action onDispose)
Microsoft.DotNet.VersionTools.Cli.Tests (1)
VersionTrimmingOperationTests.cs (1)
154Action shouldFail = () => operation.Execute();
Microsoft.DotNet.XliffTasks (1)
ExponentialRetry.cs (1)
14Action action,
Microsoft.DotNet.XUnitAssert.Tests (97)
AsyncCollectionAssertsTests.cs (15)
636 Action action, 659 void validateError(Action action) 742 Action action, 787 Action action, 868 Action action, 920 Action action, 960 Action action, 1021 Action action, 1091 void validateError(Action action) 1136 Action action, 1186 Action action, 1227 Action action, 1269 Action action, 1327 Action action, 1354 Action action,
DictionaryAssertsTests.cs (2)
41 void assertFailure(Action action) 93 void assertFailure(Action action)
EqualityAssertsTests.cs (30)
261 void assertFailure(Action action) 295 void assertFailure(Action action) 434 void assertFailure(Action action) 761 void assertFailure(Action action) 796 void assertFailure(Action action) 820 void assertFailure(Action action) 857 void assertFailure(Action action) 920 void assertFailure(Action action) 1003 void assertFailure(Action action) 1138 void assertFailure(Action action) 1172 void assertFailure(Action action) 1377 void assertFailure(Action action) 1416 void assertFailure(Action action) 1442 void assertFailure(Action action) 1481 void assertFailure(Action action) 1520 void assertFailure(Action action) 2572 void assertFailure(Action action) 2607 void assertFailure(Action action) 2745 void assertFailure(Action action) 3072 void assertFailure(Action action) 3107 void assertFailure(Action action) 3156 void assertFailure(Action action) 3215 void assertFailure(Action action) 3356 void assertFailure(Action action) 3391 void assertFailure(Action action) 3505 void assertFailure(Action action) 3563 void assertFailure(Action action) 3602 void assertFailure(Action action) 3654 void assertFailure(Action action) 3693 void assertFailure(Action action)
EventAssertsTests.cs (1)
677 public event Action? Completed;
ExceptionAssertsTests.cs (4)
19 Assert.Throws<ArgumentNullException>("testCode", () => Assert.Throws(typeof(Exception), default(Action)!)); 175 Assert.Throws<ArgumentNullException>("testCode", () => Assert.Throws<ArgumentException>(default(Action)!)); 327 Assert.Throws<ArgumentNullException>("testCode", () => Assert.Throws<ArgumentException>(default(Action)!)); 502 Assert.Throws<ArgumentNullException>("testCode", () => Assert.ThrowsAny<ArgumentException>(default(Action)!));
MemoryAssertsTests.cs (13)
433 void assertFailure(Action action) 455 void assertFailure(Action action) 486 void assertFailure(Action action) 509 void assertFailure(Action action) 637 void assertFailure(Action action) 657 void assertFailure(Action action) 734 void assertFailure(Action action) 758 void assertFailure(Action action) 814 void assertFailure(Action action) 850 void assertFailure(Action action) 872 void assertFailure(Action action) 903 void assertFailure(Action action) 926 void assertFailure(Action action)
PropertyAssertsTests.cs (1)
16 Assert.Throws<ArgumentNullException>("testCode", () => Assert.PropertyChanged(Substitute.For<INotifyPropertyChanged>(), "propertyName", (Action)null!));
SetAssertsTests.cs (2)
36 void assertFailure(Action action) 86 void assertFailure(Action action)
SpanAssertsTests.cs (13)
433 void assertFailure(Action action) 455 void assertFailure(Action action) 486 void assertFailure(Action action) 509 void assertFailure(Action action) 637 void assertFailure(Action action) 657 void assertFailure(Action action) 734 void assertFailure(Action action) 758 void assertFailure(Action action) 814 void assertFailure(Action action) 850 void assertFailure(Action action) 872 void assertFailure(Action action) 903 void assertFailure(Action action) 926 void assertFailure(Action action)
StringAssertsTests.cs (16)
29 void verify(Action action) 58 void verify(Action action) 104 void verify(Action action) 184 void verify(Action action) 220 void verify(Action action) 250 void verify(Action action) 280 void verify(Action action) 310 void verify(Action action) 447 void verify(Action action) 476 void verify(Action action) 538 void verify(Action action) 665 void verify(Action action) 707 void verify(Action action) 849 void verify(Action action) 878 void verify(Action action) 940 void verify(Action action)
Microsoft.Extensions.AI.Evaluation (1)
Utilities\TimingHelper.cs (1)
12internal static TimeSpan ExecuteWithTiming(Action operation)
Microsoft.Extensions.AI.Evaluation.Console (2)
src\Libraries\Microsoft.Extensions.AI.Evaluation\Utilities\TimingHelper.cs (1)
12internal static TimeSpan ExecuteWithTiming(Action operation)
Utilities\LoggerExtensions.cs (1)
20Action operation,
Microsoft.Extensions.AI.Evaluation.NLP (1)
src\Libraries\Microsoft.Extensions.AI.Evaluation\Utilities\TimingHelper.cs (1)
12internal static TimeSpan ExecuteWithTiming(Action operation)
Microsoft.Extensions.AI.Evaluation.Quality (1)
src\Libraries\Microsoft.Extensions.AI.Evaluation\Utilities\TimingHelper.cs (1)
12internal static TimeSpan ExecuteWithTiming(Action operation)
Microsoft.Extensions.AI.Evaluation.Safety (1)
src\Libraries\Microsoft.Extensions.AI.Evaluation\Utilities\TimingHelper.cs (1)
12internal static TimeSpan ExecuteWithTiming(Action operation)
Microsoft.Extensions.AI.Tests (1)
Functions\AIFunctionFactoryTest.cs (1)
258Action dotnetFunc = () => { };
Microsoft.Extensions.Caching.SqlServer (1)
SqlServerCache.cs (1)
28private readonly Action _deleteExpiredCachedItemsDelegate;
Microsoft.Extensions.Configuration.KeyPerFile.Tests (7)
ConfigurationProviderCommandLineTest.cs (1)
14protected override (IConfigurationProvider Provider, Action Initializer) LoadThroughProvider(
ConfigurationProviderTestBase.cs (5)
112private void AssertFormatOrArgumentException(Action test) 326protected abstract (IConfigurationProvider Provider, Action Initializer) LoadThroughProvider(TestSection testConfig); 329params (IConfigurationProvider Provider, Action Initializer)[] providers) 333foreach (var initializer in providers.Select(e => e.Initializer)) 341protected static (IConfigurationProvider Provider, Action Initializer) LoadUsingMemoryProvider(TestSection testConfig)
KeyPerFileTests.cs (1)
457private Action _callback;
Microsoft.Extensions.Diagnostics.HealthChecks.Tests (1)
src\Shared\test\Shared.Tests\SingleThreadedSynchronizationContext.cs (1)
26public static void Run(Action action)
Microsoft.Extensions.Diagnostics.Probes.Tests (1)
KubernetesProbesOptionsValidatorTests.cs (1)
100Action action = () =>
Microsoft.Extensions.Http.Polly.Tests (1)
src\Shared\test\Shared.Tests\SingleThreadedSynchronizationContext.cs (1)
26public static void Run(Action action)
Microsoft.Extensions.Http.Resilience (1)
Resilience\ResilienceHandlerContext.cs (1)
70public void OnPipelineDisposed(Action callback) => _context.OnPipelineDisposed(Throw.IfNull(callback));
Microsoft.Extensions.ML (1)
ServiceCollectionExtensions.cs (1)
59Action callback)
Microsoft.Extensions.Options (3)
StartupValidatorOptions.cs (2)
12public Dictionary<(Type, string), Action> _validators { get; } = new Dictionary<(Type, string), Action>();
ValidateOnStart.cs (1)
24foreach (Action validator in _validatorOptions._validators.Values)
Microsoft.Extensions.Primitives (2)
ChangeToken.cs (2)
20public static IDisposable OnChange(Func<IChangeToken?> changeTokenProducer, Action changeTokenConsumer) 31return new ChangeTokenRegistration<Action>(changeTokenProducer, callback => callback(), changeTokenConsumer);
Microsoft.Extensions.SecretManager.Tools.Tests (2)
UserSecretsTestFixture.cs (2)
13private Stack<Action> _disposables = new Stack<Action>();
Microsoft.Extensions.ServiceDiscovery.Tests (1)
ExtensionsServicePublicApiTests.cs (1)
182var action = () =>
Microsoft.Gen.ComplianceReports (2)
Emitter.cs (2)
143private void OutObject(Action action) 161private void OutArray(string name, Action action)
Microsoft.Gen.Logging.Generated.Tests (1)
test\Generators\Microsoft.Gen.Logging\TestClasses\LogPropertiesExtensions.cs (1)
32public Action? ActionBase { get; set; } // Not supposed to be logged (delegate type)
Microsoft.Gen.MetadataExtractor (2)
src\Generators\Microsoft.Gen.ComplianceReports\Emitter.cs (2)
143private void OutObject(Action action) 161private void OutArray(string name, Action action)
Microsoft.Maui (28)
Animations\Animation.cs (2)
30 public Animation(Action<double> callback, double start = 0.0f, double duration = 1.0f, Easing? easing = null, Action? finished = null) 54 public Action? Finished { get; set; }
Animations\ITicker.cs (2)
27 /// The <see cref="Action"/> that is triggered when this ticker interval has been reached. 29 Action? Fire { get; set; }
Animations\LerpingAnimation.cs (2)
26 public LerpingAnimation(Action<double> callback, double start = 0, double end = 1, Easing? easing = null, Action? finished = null) 43 public Action? ValueChanged { get; set; }
Animations\Ticker.cs (1)
16 public Action? Fire { get; set; }
Dispatching\Dispatcher.cs (2)
16 public bool Dispatch(Action action) 24 public bool DispatchDelayed(TimeSpan delay, Action action)
Dispatching\Dispatcher.Standard.cs (2)
15 bool DispatchImplementation(Action action) => 18 bool DispatchDelayedImplementation(TimeSpan delay, Action action) =>
Dispatching\DispatcherExtensions.cs (1)
45 public static Task DispatchAsync(this IDispatcher dispatcher, Action action) =>
Dispatching\IDispatcher.cs (4)
13 /// <param name="action">The <see cref="Action"/> to be scheduled for processing on the UI thread.</param> 15 bool Dispatch(Action action); 21 /// <param name="action">The <see cref="Action"/> to be scheduled for processing on the UI thread.</param> 23 bool DispatchDelayed(TimeSpan delay, Action action);
ImageSources\ImageSourceServiceResult.cs (6)
19 Action? _dispose; 25 public ImageSourceServiceLoadResult(Action? dispose = null) 30 public ImageSourceServiceLoadResult(bool resolutionDependent, Action? dispose = null) 54 Action? _dispose; 56 public ImageSourceServiceResult(PlatformView image, Action? dispose = null) 61 public ImageSourceServiceResult(PlatformView image, bool resolutionDependent, Action? dispose = null)
LifecycleEvents\LifecycleBuilderExtensions.cs (1)
9 public static ILifecycleBuilder AddEvent(this ILifecycleBuilder builder, string eventName, Action action)
LifecycleEvents\LifecycleEventServiceExtensions.cs (1)
11 lifecycleService.InvokeEvents<Action>(eventName, action => action?.Invoke());
Platform\ActionDisposable.cs (2)
10 volatile Action? _action; 11 public ActionDisposable(Action action)
Platform\ViewExtensions.cs (2)
129 internal static IDisposable OnUnloaded(this IElement element, Action action) 148 internal static IDisposable OnLoaded(this IElement element, Action action)
Microsoft.Maui.Controls (32)
Animation.cs (1)
32 public Animation(Action<double> callback, double start = 0.0f, double end = 1.0f, Easing easing = null, Action finished = null) : base(callback, start, end - start, easing, finished)
AnimationExtensions.cs (6)
124 Action abort = () => 184 Action animate = () => AnimateInternal(self, animationManager, name, transform, callback, rate, length, easing, finished, repeat); 191 public static void AnimateKinetic(this IAnimatable self, string name, Func<double, double, bool> callback, double velocity, double drag, Action finished = null, IAnimationManager animationManager = null) 196 Action animate = () => AnimateKineticInternal(self, animationManager, name, callback, velocity, drag, finished); 286 static void AnimateKineticInternal(IAnimatable self, IAnimationManager animationManager, string name, Func<double, double, bool> callback, double velocity, double drag, Action finished = null) 376 static void DoAction(IAnimatable self, Action action)
CollectionSynchronizationCallback.cs (1)
7 public delegate void CollectionSynchronizationCallback(IEnumerable collection, object context, Action accessMethod, bool writeAccess);
Command.cs (2)
80 public Command(Action execute) : this(o => execute()) 96 public Command(Action execute, Func<bool> canExecute) : this(o => execute(), o => canExecute())
Device.cs (2)
90 public static void BeginInvokeOnMainThread(Action action) => 100 public static Task InvokeOnMainThreadAsync(Action action) =>
DispatcherExtensions.cs (2)
50 public static void DispatchIfRequired(this IDispatcher? dispatcher, Action action) 63 public static Task DispatchIfRequiredAsync(this IDispatcher? dispatcher, Action action)
Internals\NotifyCollectionChangedEventArgsExtensions.cs (1)
25 public static NotifyCollectionChangedAction Apply(this NotifyCollectionChangedEventArgs self, Action<object, int, bool> insert, Action<object, int> removeAt, Action reset)
Internals\ProfilePage.cs (1)
138 Action update = delegate ()
ListProxy.cs (3)
203 Action action; 258 Action getFromList = () => 324 Action move = () =>
NavigationPage\NavigationPage.cs (3)
615 Action processStackChanges, 616 Action firePostNavigatingEvents, 617 Action fireNavigatedEvents)
Page\Page.cs (4)
81 List<Action> _pendingActions = new List<Action>(); 388 foreach (var pendingAction in actionsToProcess) 643 internal void OnAppearing(Action action)
Shell\BaseShellItem.cs (1)
169 internal void OnAppearing(Action action)
Shell\ShellNavigatingDeferral.cs (3)
11 Action _completed; 13 internal ShellNavigatingDeferral(Action completed) 21 var taskToComplete = Interlocked.Exchange(ref _completed, null);
Toolbar\ToolbarItem.cs (1)
23 public ToolbarItem(string name, string icon, Action activated, ToolbarItemOrder order = ToolbarItemOrder.Default, int priority = 0)
ViewExtensions.cs (1)
474 static internal void MapFocus(this VisualElement view, FocusRequest focusRequest, Action? baseMethod = null)
Microsoft.Maui.Controls.Foldable (3)
DualScreenInfo.cs (1)
221 Action onChanged = null)
NoPlatformFoldableService.cs (1)
61 public object WatchForChangesOnLayout(VisualElement visualElement, Action action)
TwoPaneViewLayoutGuide.cs (1)
390 Action onChanged = null)
Microsoft.Maui.Essentials (3)
MainThread\MainThread.netstandard.cs (1)
7 static void PlatformBeginInvokeOnMainThread(Action action) =>
MainThread\MainThread.shared.cs (2)
22 public static void BeginInvokeOnMainThread(Action action) 39 public static Task InvokeOnMainThreadAsync(Action action)
Microsoft.Maui.Resizetizer (1)
AsyncTaskExtensions.cs (1)
40 public static Task RunTask(this MauiAsyncTask asyncTask, Action body) =>
Microsoft.ML.AutoML.Interactive (2)
ActionThrottler.cs (2)
16private readonly Action _action; 27public ActionThrottler(Action action, TimeSpan minDelay)
Microsoft.ML.Core (12)
Data\ServerChannel.cs (2)
235internal Action Done; 245public void AddDoneAction(Action onDone)
Utilities\ThreadUtils.cs (4)
15public static Task RunOnBackgroundThreadAsync(Action start) => 40/// Queues an <see cref="Action"/> delegate to be executed immediately on another thread, 45public static Task QueueAsync(Action threadStart) => QueueAsync((Delegate)threadStart, null); 86((Action)item.action)();
Utilities\Utils.cs (6)
1198/// <see cref="Action"/> instead of <see cref="Func{TRet}"/>. 1204public static void MarshalActionInvoke(Action act, Type genArg) 1211/// A one-argument version of <see cref="MarshalActionInvoke(Action, Type)"/>. 1220/// A two-argument version of <see cref="MarshalActionInvoke(Action, Type)"/>. 1229/// A three-argument version of <see cref="MarshalActionInvoke(Action, Type)"/>. 1238/// A four-argument version of <see cref="MarshalActionInvoke(Action, Type)"/>.
Microsoft.ML.Data (64)
Data\DataViewUtils.cs (6)
398Action pushBatch = () => 465Action quitAction = () => 570Action pushBatch = () => 608Action quitAction = () => 1006private readonly Action _quitAction; 1028OutPipe[] pipes, BlockingCollection<Batch> batchInputs, Action quitAction)
DataLoadSave\Binary\BinaryLoader.cs (1)
196Action del = AssertGeneratorValid<int>;
DataView\LambdaColumnMapper.cs (1)
154protected override Delegate GetGetterCore(IChannel ch, DataViewRow input, int iinfo, out Action disposer)
DataView\RowToRowMapperTransform.cs (5)
43Delegate[] CreateGetters(DataViewRow input, Func<int, bool> activeOutput, out Action disposer); 264var getters = _mapper.CreateGetters(input, pred, out Action disp); 303private readonly Action _disposer; 307public RowImpl(DataViewRow input, RowToRowMapperTransform parent, DataViewSchema schema, Delegate[] getters, Action disposer) 363private readonly Action _disposer;
DataView\SimpleRow.cs (2)
23private readonly Action _disposer; 37public SimpleRow(DataViewSchema schema, DataViewRow input, Delegate[] getters, Action disposer = null)
DataView\Transposer.cs (1)
555Action copyPhase =
Evaluators\BinaryClassifierEvaluator.cs (2)
1148private protected override Delegate[] CreateGettersCore(DataViewRow input, Func<int, bool> activeCols, out Action disposer) 1175Action updateCacheIfNeeded;
Evaluators\ClusteringEvaluator.cs (2)
649private protected override Delegate[] CreateGettersCore(DataViewRow input, Func<int, bool> activeCols, out Action disposer) 664Action updateCacheIfNeeded =
Evaluators\EvaluatorBase.cs (2)
537Delegate[] IRowMapper.CreateGetters(DataViewRow input, Func<int, bool> activeCols, out Action disposer) 541private protected abstract Delegate[] CreateGettersCore(DataViewRow input, Func<int, bool> activeCols, out Action disposer);
Evaluators\MulticlassClassificationEvaluator.cs (2)
709private protected override Delegate[] CreateGettersCore(DataViewRow input, Func<int, bool> activeCols, out Action disposer) 727Action updateCacheIfNeeded =
Evaluators\MultiOutputRegressionEvaluator.cs (2)
460private protected override Delegate[] CreateGettersCore(DataViewRow input, Func<int, bool> activeCols, out Action disposer) 478Action updateCacheIfNeeded =
Evaluators\QuantileRegressionEvaluator.cs (2)
380private protected override Delegate[] CreateGettersCore(DataViewRow input, Func<int, bool> activeCols, out Action disposer) 399Action updateCacheIfNeeded =
Evaluators\RankingEvaluator.cs (1)
427private Action _groupSbUpdate;
Evaluators\RegressionEvaluator.cs (2)
269private protected override Delegate[] CreateGettersCore(DataViewRow input, Func<int, bool> activeCols, out Action disposer) 287Action updateCacheIfNeeded =
Prediction\CalibratorCatalog.cs (1)
313protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer)
Prediction\PredictionEngine.cs (2)
95private readonly Action _disposer; 124IRowToRowMapper mapper, bool ignoreMissingColumns, SchemaDefinition outputSchemaDefinition, out Action disposer, out IRowReadableAs<TDst> outputRow)
Scorers\RowToRowScorerBase.cs (1)
165protected override Delegate[] CreateGetters(DataViewRow input, IEnumerable<DataViewSchema.Column> activeColumns, out Action disp)
Transforms\ColumnConcatenatingTransformer.cs (1)
875protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer)
Transforms\ColumnCopying.cs (1)
213protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer)
Transforms\FeatureContributionCalculationTransformer.cs (1)
203protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> active, out Action disposer)
Transforms\Hashing.cs (3)
232Action disposer = null; 261private Delegate GetGetterCore(DataViewRow input, int iinfo, out Action disposer) 1354protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer) => _parent.GetGetterCore(input, iinfo, out disposer);
Transforms\KeyToValue.cs (1)
212protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer)
Transforms\KeyToVector.cs (1)
449protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer)
Transforms\LabelConvertTransform.cs (1)
170protected override Delegate GetGetterCore(IChannel ch, DataViewRow input, int iinfo, out Action disposer)
Transforms\LabelIndicatorTransform.cs (1)
168int iinfo, out Action disposer)
Transforms\Normalizer.cs (1)
756protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer)
Transforms\RowToRowTransformerBase.cs (4)
78public virtual Delegate[] CreateGetters(DataViewRow input, Func<int, bool> activeOutput, out Action disposer) 87var disposers = new Action[n]; 98foreach (var act in disposers) 107protected abstract Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer);
Transforms\SlotsDroppingTransformer.cs (1)
719protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer)
Transforms\TransformBase.cs (10)
184var getters = CreateGetters(input, activeColumns, out Action disp); 189protected abstract Delegate[] CreateGetters(DataViewRow input, IEnumerable<DataViewSchema.Column> activeColumns, out Action disp); 197private readonly Action _disposer; 203public RowImpl(DataViewRow input, RowToRowMapperTransformBase parent, DataViewSchema schema, Delegate[] getters, Action disposer) 692protected abstract Delegate GetGetterCore(IChannel ch, DataViewRow input, int iinfo, out Action disposer); 818protected override Delegate[] CreateGetters(DataViewRow input, IEnumerable<DataViewSchema.Column> activeColumns, out Action disposer) 836Action disp; 850private readonly Action _disposer; 864Action masterDisposer = null; 869_getters[iinfo] = parent.GetGetterCore(Ch, Input, iinfo, out Action disposer);
Transforms\TypeConverting.cs (1)
467protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer)
Transforms\ValueMapping.cs (1)
1048protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer)
Transforms\ValueToKeyMappingTransformer.cs (1)
756protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer)
Microsoft.ML.Ensemble (7)
PipelineEnsemble.cs (7)
110var scoreGetter = CreateScoreGetter(input, out Action disposer); 114internal abstract Delegate CreateScoreGetter(DataViewRow input, out Action disposer); 130internal override Delegate CreateScoreGetter(DataViewRow input, out Action disposer) 162public ValueGetter<Single> GetLabelGetter(DataViewRow input, int i, out Action disposer) 174public ValueGetter<Single> GetWeightGetter(DataViewRow input, int i, out Action disposer) 333var scoreGetter = (ValueGetter<Single>)bound.CreateScoreGetter(curs, out Action disposer); 337var labelGetter = bound.GetLabelGetter(curs, 0, out Action disp);
Microsoft.ML.FastTree (22)
FastTreeRanking.cs (1)
124Action error =
GamClassification.cs (1)
122var actions = new Action[(int)Math.Ceiling(1.0 * targets.Length / innerLoopSize)];
Training\Applications\ObjectiveFunction.cs (1)
63var actions = new Action[(int)Math.Ceiling((double)Dataset.NumQueries / QueryThreadChunkSize)];
Training\DcgCalculator.cs (2)
371var actions = new Action[(int)Math.Ceiling(1.0 * dataset.NumQueries / chunkSize)]; 510var actions = new Action[(int)Math.Ceiling(1.0 * dataset.NumQueries / chunkSize)];
Training\DocumentPartitioning.cs (2)
71var actions = new Action[(int)Math.Ceiling(1.0 * dataset.NumDocs / innerLoopSize)]; 111actions = new Action[tree.NumLeaves];
Training\ScoreTracker.cs (2)
175var actions = new Action[(int)Math.Ceiling(1.0 * Dataset.NumDocs / innerLoopSize)]; 202var actions = new Action[tree.NumLeaves];
Training\Test.cs (3)
541var actions = new Action[(int)Math.Ceiling(1.0 * Dataset.NumDocs / chunkSize)]; 619var actions = new Action[(int)Math.Ceiling(1.0 * binaryLabels.Length / chunkSize)]; 659var actions = new Action[(int)Math.Ceiling(1.0 * Dataset.NumDocs / chunkSize)];
Training\WinLossCalculator.cs (1)
53var actions = new Action[(int)Math.Ceiling(1.0 * dataset.NumQueries / chunkSize)];
TreeEnsemble\InternalRegressionTree.cs (3)
1382var actions = new Action[(int)Math.Ceiling(1.0 * dataset.NumDocs / innerLoopSize)]; 1407var actions = new Action[(int)Math.Ceiling(1.0 * dataset.NumDocs / innerLoopSize)]; 1430var actions = new Action[(int)Math.Ceiling(1.0 * docIndices.Length / innerLoopSize)];
TreeEnsemble\InternalTreeEnsemble.cs (1)
296var actions = new Action[(int)Math.Ceiling(1.0 * dataset.NumDocs / innerLoopSize)];
Utils\ThreadTaskManager.cs (5)
37private readonly Action[] _actions; 39public ThreadTask(int num, IEnumerable<Action> actions) 68public static IThreadTask MakeTask(IEnumerable<Action> subTasks) 81IEnumerable<Action> subTasks = 83.Select<int, Action>(arg => (() => subTaskAction(arg)));
Microsoft.ML.ImageAnalytics (8)
ImageGrayscale.cs (1)
162protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer)
ImageLoader.cs (3)
206protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer) 216private Delegate MakeGetterImageDataViewType(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer) 263private Delegate MakeGetterVectorDataViewByteType(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer)
ImagePixelExtractor.cs (2)
294protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer) 305private ValueGetter<VBuffer<TValue>> GetGetterCore<TValue>(DataViewRow input, int iinfo, out Action disposer)
ImageResizer.cs (1)
272protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer)
VectorToImageTransform.cs (1)
325protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer)
Microsoft.ML.KMeansClustering (4)
KMeansPlusPlusTrainer.cs (4)
1383Action[] ops = new Action[set.Length]; 1722Action[] workArr = new Action[numCursors];
Microsoft.ML.LightGbm (1)
LightGbmRankingTrainer.cs (1)
272Action error =
Microsoft.ML.Mkl.Components (1)
VectorWhitening.cs (1)
597protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer)
Microsoft.ML.OnnxTransformer (2)
OnnxTransform.cs (2)
615protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer) 641public override Delegate[] CreateGetters(DataViewRow input, Func<int, bool> activeOutput, out Action disposer)
Microsoft.ML.PCA (1)
PcaTransformer.cs (1)
569protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer)
Microsoft.ML.TensorFlow (2)
TensorflowTransform.cs (2)
653public override Delegate[] CreateGetters(DataViewRow input, Func<int, bool> activeOutput, out Action disposer) 698protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer)
Microsoft.ML.TestFramework (2)
DataPipe\TestDataPipeBase.cs (2)
40Action<Action> mustFail = (Action action) =>
Microsoft.ML.Tests (2)
Scenarios\GetColumnTests.cs (2)
93private static Action<Action> GetMustFail() 95return (Action action) =>
Microsoft.ML.TimeSeries (17)
PredictionEngine.cs (2)
44Action<PingerArgument> CreatePinger(DataViewRow input, Func<int, bool> activeOutput, out Action disposer); 218IRowToRowMapper mapper, bool ignoreMissingColumns, SchemaDefinition outputSchemaDefinition, out Action disposer, out IRowReadableAs<TDst> outputRow)
SequentialAnomalyDetectionTransformBase.cs (2)
352public Delegate[] CreateGetters(DataViewRow input, Func<int, bool> activeOutput, out Action disposer) 380public Action<PingerArgument> CreatePinger(DataViewRow input, Func<int, bool> activeOutput, out Action disposer)
SequentialForecastingTransformBase.cs (2)
156public Delegate[] CreateGetters(DataViewRow input, Func<int, bool> activeOutput, out Action disposer) 221public Action<PingerArgument> CreatePinger(DataViewRow input, Func<int, bool> activeOutput, out Action disposer)
SequentialTransformerBase.cs (9)
613var getters = _mapper.CreateGetters(input, active, out Action disposer); 614var pingers = _mapper.CreatePinger(input, active, out Action pingerDisposer); 625private readonly Action _disposer; 635public RowImpl(ColumnBindings bindings, DataViewRow input, Delegate[] getters, Action<PingerArgument> pinger, Action disposer) 938var getters = _mapper.CreateGetters(input, pred, out Action disp); 939var pingers = _mapper.CreatePinger(input, pred, out Action pingerDisp); 949private readonly Action _disposer; 960DataViewSchema schema, Delegate[] getters, Action<PingerArgument> pinger, Action disposer) 1022private readonly Action _disposer;
SrCnnTransformBase.cs (2)
195public Delegate[] CreateGetters(DataViewRow input, Func<int, bool> activeOutput, out Action disposer) 223public Action<PingerArgument> CreatePinger(DataViewRow input, Func<int, bool> activeOutput, out Action disposer)
Microsoft.ML.Tokenizers.Data.Tests (1)
src\Common\tests\RetryHelper.cs (1)
24public static void Execute(Action test, int maxAttempts = 5, Func<int, int>? backoffFunc = null, Predicate<Exception>? retryWhen = null, [CallerMemberName] string? testName = null)
Microsoft.ML.Tokenizers.Tests (1)
src\Common\tests\RetryHelper.cs (1)
24public static void Execute(Action test, int maxAttempts = 5, Func<int, int>? backoffFunc = null, Predicate<Exception>? retryWhen = null, [CallerMemberName] string? testName = null)
Microsoft.ML.TorchSharp (7)
AutoFormerV2\ObjectDetectionTrainer.cs (2)
790protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer) 876public override Delegate[] CreateGetters(DataViewRow input, Func<int, bool> activeOutput, out Action disposer)
NasBert\NasBertTrainer.cs (1)
566protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer)
Roberta\QATrainer.cs (2)
761protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer) 827public override Delegate[] CreateGetters(DataViewRow input, Func<int, bool> activeOutput, out Action disposer)
TorchSharpBaseTrainer.cs (2)
485protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer) 490public override Delegate[] CreateGetters(DataViewRow input, Func<int, bool> activeOutput, out Action disposer)
Microsoft.ML.Transforms (32)
CountFeatureSelection.cs (1)
385private readonly Action _fillBuffer;
CustomMappingFilter.cs (2)
105Action refresh = () => 173Action refresh = () =>
CustomMappingTransformer.cs (3)
130Delegate[] IRowMapper.CreateGetters(DataViewRow input, Func<int, bool> activeOutput, out Action disposer) 145Action refresh = () => 166private Delegate GetDstGetter<T>(DataViewRow input, int colIndex, Action refreshAction)
Dracula\CountTableTransformer.cs (1)
672protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer)
ExpressionTransformer.cs (1)
966protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer)
GcnTransform.cs (1)
360protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer)
HashJoiningTransform.cs (1)
466protected override Delegate GetGetterCore(IChannel ch, DataViewRow input, int iinfo, out Action disposer)
KeyToVectorMapping.cs (1)
336protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer)
MissingValueDroppingTransformer.cs (1)
217protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer)
MissingValueIndicatorTransform.cs (1)
237protected override Delegate GetGetterCore(IChannel ch, DataViewRow input, int iinfo, out Action disposer)
MissingValueIndicatorTransformer.cs (1)
235protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer)
MissingValueReplacing.cs (1)
622protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer)
OptionalColumnTransform.cs (1)
375protected override Delegate[] CreateGetters(DataViewRow input, IEnumerable<DataViewSchema.Column> activeColumns, out Action disposer)
RandomFourierFeaturizing.cs (1)
502protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer)
StatefulCustomMappingTransformer.cs (4)
158protected override Delegate[] CreateGetters(DataViewRow input, IEnumerable<DataViewSchema.Column> activeColumns, out Action disp) 172Action refresh = () => 195private Delegate GetDstGetter<T>(DataViewRow input, string colName, Action refreshAction) 291Action refresh = () =>
Text\LdaTransform.cs (1)
596protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer)
Text\NgramHashingTransformer.cs (2)
235Action disp; 558protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer)
Text\NgramTransform.cs (1)
670protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer)
Text\StopWordsRemovingTransformer.cs (2)
402protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer) 1096protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer)
Text\TextNormalizing.cs (1)
326protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer)
Text\TokenizingByCharacters.cs (1)
464protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer)
Text\WordBagTransform.cs (1)
300protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer)
Text\WordEmbeddingsExtractor.cs (1)
543protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer)
Text\WordTokenizing.cs (1)
234protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer)
Microsoft.ML.Vision (1)
DnnRetrainTransform.cs (1)
855protected override Delegate MakeGetter(DataViewRow input, int iinfo, Func<int, bool> activeOutput, out Action disposer)
Microsoft.VisualBasic.Tests (12)
Microsoft\VisualBasic\ApplicationServices\AssemblyInfoTests.cs (1)
13Action action = () => new AssemblyInfo(null);
Microsoft\VisualBasic\Devices\AudioTests.cs (9)
17Action testCode = () => audio.Play(null); 26Action testCode = () => audio.Play(([0]), audioPlayMode); 35Action testCode = () => audio.Play(fileName); 44Action testCode = () => audio.Play(fileName, AudioPlayMode.Background); 54Action testCode = () => audio.Play(location, audioPlayMode); 63Action testCode = () => audio.Play((string)null, mode); 71Action testCode = () => audio.Play((MemoryStream)null, AudioPlayMode.Background); 79Action testCode = () => audio.PlaySystemSound((SystemSound)null); 87Action testCode = audio.Stop;
Microsoft\VisualBasic\Devices\NetworkTests.cs (2)
52Action action = () => network.Ping((Uri)null); 60Action action = () => network.Ping((Uri)null, 1);
Microsoft.VisualStudio.LanguageServices (10)
DebuggerIntelliSense\DebuggerTextView.cs (1)
353public void QueuePostLayoutAction(Action action) => _innerTextView.QueuePostLayoutAction(action);
ErrorReporting\VisualStudioInfoBar.cs (2)
181private readonly Action _onClose; 183public InfoBarEvents(InfoBarUI[] items, Action onClose)
Implementation\VisualStudioUIContextActivationService.cs (3)
19public IDisposable ExecuteWhenActivated(Guid uiContext, Action action) 44private readonly Action _action; 47public WhenActivatedHandler(UIContext context, Action action)
InlineRename\InlineRenameUndoManager.cs (1)
101public void CreateConflictResolutionUndoTransaction(ITextBuffer subjectBuffer, Action applyEdit)
ProjectSystem\VisualStudioWorkspaceImpl.cs (2)
1225Action GetDefaultDismissAction(Action? additionalAction = null)
Snippets\AbstractSnippetCommandHandler.cs (1)
108public void ExecuteCommand(AutomaticLineEnderCommandArgs args, Action nextCommandHandler, CommandExecutionContext executionContext)
Microsoft.VisualStudio.LanguageServices.CSharp (1)
Snippets\SnippetCommandHandler.cs (1)
85public void ExecuteCommand(TypeCharCommandArgs args, Action nextCommandHandler, CommandExecutionContext executionContext)
Microsoft.VisualStudio.LanguageServices.CSharp.UnitTests (2)
PersistentStorage\SQLiteV2PersistentStorageTests.cs (2)
64private readonly Action? _onNewConnection; 68Action? onNewConnection = null,
Microsoft.VisualStudio.LanguageServices.Implementation (3)
CodeModel\FileCodeModel.cs (1)
307internal void EnsureEditor(Action action)
SolutionExplorer\ContextMenuController.cs (2)
20private readonly Action _updateMenu; 22public ContextMenuController(int menuId, Func<IEnumerable<object>, bool> shouldShowMenu, Action updateMenu)
mscorlib (1)
src\libraries\shims\mscorlib\ref\mscorlib.cs (1)
29[assembly: System.Runtime.CompilerServices.TypeForwardedTo(typeof(System.Action))]
netstandard (1)
netstandard.cs (1)
17[assembly: System.Runtime.CompilerServices.TypeForwardedTo(typeof(System.Action))]
PresentationCore (4)
System\Windows\Input\InputManager.cs (2)
759_synchronizedInputAsyncClearOperation = Dispatcher.BeginInvoke((Action)delegate 797_synchronizedInputAsyncClearOperation = Dispatcher.BeginInvoke((Action)delegate
System\Windows\Input\Stylus\Common\StylusPlugInCollection.cs (2)
459internal void ExecuteWithPotentialLock(Action action) 483internal void ExecuteWithPotentialDispatcherDisable(Action action)
PresentationCore.Tests (17)
System\Windows\ClipboardTests.cs (8)
54Action action = () => Clipboard.SetAudio((byte[])null!); 87Action action = () => Clipboard.SetAudio((Stream)null!); 111Action action = () => Clipboard.SetData(format!, "data"); 118Action action = () => Clipboard.SetData("MyData", data: null!); 125Action action = () => Clipboard.SetData("MyData", data: null!); 156Action action = () => Clipboard.SetFileDropList(null!); 163Action action = static () => Clipboard.SetFileDropList([]); 177Action action = () => Clipboard.SetFileDropList(filePaths);
System\Windows\DataObjectTests.cs (9)
55Action action = () => data.SetData(null!); 81Action action = () => data.SetData((string)null!, "Some Data"); 132Action act = () => data.SetData(key, testData); 143Action act = () => data.SetData(string.Empty, testData); 207Action act = () => data.SetData(key!, testData); 218Action act = () => data.SetData(key, null); 272Action act = () => data.SetData(key, null, true); 283Action act = () => data.SetData((string)null!, testData, true); 294Action act = () => data.SetData(string.Empty, testData, true);
PresentationFramework (36)
MS\Internal\Data\DataBindEngine.cs (2)
498(Action)ProcessCrossThreadRequests); 561(Action)ProcessCrossThreadRequests);
MS\Internal\Data\ValueTable.cs (1)
70Action FetchAndCacheValue = () =>
MS\Internal\Data\ViewManager.cs (2)
387public void AccessCollection(IEnumerable collection, Action accessMethod, bool writeAccess) 667Action accessMethod,
System\Windows\Controls\DataGrid.cs (1)
4046Dispatcher.BeginInvoke((Action)delegate ()
System\Windows\Controls\DataGridHyperlinkColumn.cs (1)
295Dispatcher.Invoke((Action)delegate(){}, System.Windows.Threading.DispatcherPriority.Background);
System\Windows\Controls\DataGridTextColumn.cs (1)
280Dispatcher.Invoke((Action)delegate(){}, System.Windows.Threading.DispatcherPriority.Background);
System\Windows\Controls\DatePicker.cs (1)
349dp.Dispatcher.BeginInvoke(DispatcherPriority.Input, (Action)delegate()
System\Windows\Controls\VirtualizingStackPanel.cs (9)
798DispatcherOperation anchorOperation = Dispatcher.BeginInvoke(DispatcherPriority.Render, (Action)OnAnchorOperation); 867DispatcherOperation anchorOperation = Dispatcher.BeginInvoke(DispatcherPriority.Background, (Action)OnAnchorOperation); 1060DispatcherOperation anchorOperation = Dispatcher.BeginInvoke(DispatcherPriority.Render, (Action)OnAnchorOperation); 1421(Action)delegate() 1711Dispatcher.BeginInvoke(DispatcherPriority.Loaded, (Action)delegate() 4348Action measureCachesAction = null; 4350measureCachesAction = (Action)delegate() 4425(Action)ClearIsScrollActive); 4444(Action)ClearIsScrollActive);
System\Windows\Data\BindingListCollectionView.cs (6)
2415Dispatcher.BeginInvoke(DispatcherPriority.DataBind, (Action)RestoreLiveShaping); 2473private void DeferAction(Action action) 2477_deferredActions = new List<Action>(); 2487List<Action> deferredActions = _deferredActions; 2490foreach(Action action in deferredActions) 2549private List<Action> _deferredActions;
System\Windows\Data\BindingOperations.cs (1)
359Action accessMethod,
System\Windows\Data\CollectionSynchronizationCallback.cs (1)
40Action accessMethod,
System\Windows\Data\ListCollectionView.cs (6)
3249Dispatcher.BeginInvoke(DispatcherPriority.DataBind, (Action)RestoreLiveShaping); 3273private void DeferAction(Action action) 3277_deferredActions = new List<Action>(); 3287List<Action> deferredActions = _deferredActions; 3290foreach(Action action in deferredActions) 3326private List<Action> _deferredActions;
System\Windows\Diagnostics\ResourceDictionaryDiagnostics.cs (1)
496_cleanupOperation = dispatcher.BeginInvoke(DispatcherPriority.Background, (Action)DoCleanup);
System\Windows\Documents\MsSpellCheckLib\Utils\RetryHelper.cs (3)
29internal delegate bool RetryActionPreamble(out Action action); 48Action action, 104Action action,
Roslyn.Diagnostics.Analyzers (15)
src\Dependencies\PooledObjects\PooledDelegates.cs (5)
37/// Gets an <see cref="Action"/> delegate, which calls <paramref name="unboundAction"/> with the specified 65public static Releaser GetPooledAction<TArg>(Action<TArg> unboundAction, TArg argument, out Action boundAction) 66=> GetPooledDelegate<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action>(unboundAction, argument, out boundAction); 384: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action> 386protected override Action Bind()
src\Dependencies\Threading\ConfiguredYieldAwaitable.cs (3)
36static continuation => ((Action)continuation!)(); 52public void OnCompleted(Action continuation) 66public void UnsafeOnCompleted(Action continuation)
src\Dependencies\Threading\TaskExtensions.cs (2)
104public void OnCompleted(Action continuation) 114public void UnsafeOnCompleted(Action continuation)
src\Dependencies\Threading\ValueTaskExtensions.cs (4)
135public void OnCompleted(Action continuation) 145public void UnsafeOnCompleted(Action continuation) 235public void OnCompleted(Action continuation) 245public void UnsafeOnCompleted(Action continuation)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Extensions\Compilation\CompilationExtensions.cs (1)
136=> compilation.GetTypeByMetadataName(typeof(Action).FullName!);
Roslyn.Test.PdbUtilities (1)
EditAndContinue\EditAndContinueTest.GenerationVerifier.cs (1)
42private void Verify(Action action)
Roslyn.VisualStudio.DiagnosticsWindow (2)
Panels\TelemetryPanel.xaml.cs (2)
142private readonly Action _action; 144public RAII(Action disposeAction)
Roslyn.VisualStudio.Next.UnitTests (1)
Services\ServiceHubServicesTests_ExtensionMessageHandler.cs (1)
751Action? unload = null) : IExtensionAssemblyLoader
RunTests (1)
ConsoleUtil.cs (1)
50private static void WithColor(ConsoleColor color, Action action)
ScenarioTests.Common.Tests (1)
ScenarioTestTypes.cs (1)
249public static void Run(Action asyncMethod)
System.ComponentModel.Composition (24)
System\ComponentModel\Composition\ExportFactoryOfT.cs (3)
8private readonly Func<Tuple<T, Action>> _exportLifetimeContextCreator; 10public ExportFactory(Func<Tuple<T, Action>> exportLifetimeContextCreator) 19Tuple<T, Action> untypedLifetimeContext = _exportLifetimeContextCreator.Invoke();
System\ComponentModel\Composition\ExportFactoryOfTTMetadata.cs (1)
10public ExportFactory(Func<Tuple<T, Action>> exportLifetimeContextCreator, TMetadata metadata)
System\ComponentModel\Composition\ExportLifetimeContextOfT.cs (2)
9private readonly Action _disposeAction; 11public ExportLifetimeContext(T value, Action disposeAction)
System\ComponentModel\Composition\Hosting\AtomicComposition.cs (10)
40private List<Action>? _completeActionList; 41private List<Action>? _revertActionList; 88public void AddCompleteAction(Action completeAction) 96_completeActionList ??= new List<Action>(); 100public void AddRevertAction(Action revertAction) 108_revertActionList ??= new List<Action>(); 157Action action = _revertActionList[i]; 192foreach (Action action in _completeActionList) 233foreach (Action action in _completeActionList) 241foreach (Action action in _revertActionList)
System\ComponentModel\Composition\Hosting\AtomicCompositionExtensions.cs (2)
27internal static void AddRevertActionAllowNull(this AtomicComposition? atomicComposition, Action action) 41internal static void AddCompleteActionAllowNull(this AtomicComposition? atomicComposition, Action action)
System\ComponentModel\Composition\Hosting\CompositionServices.cs (1)
561internal static CompositionResult TryInvoke(Action action)
System\ComponentModel\Composition\ReflectionModel\ExportfactoryCreator.cs (2)
49Func<Tuple<T, Action>> exportLifetimeContextCreator = () => LifetimeContext.GetExportLifetimeContextFromExport<T>(export); 62Func<Tuple<T, Action>> exportLifetimeContextCreator = () => LifetimeContext.GetExportLifetimeContextFromExport<T>(export);
System\ComponentModel\Composition\ReflectionModel\ExportfactoryCreator.LifetimeContext.cs (3)
14public static Tuple<T, Action> GetExportLifetimeContextFromExport<T>(Export export) 17Action disposeAction; 57return new Tuple<T, Action>(exportedValue, disposeAction);
System.Composition.Hosting (10)
System\Composition\Hosting\Core\CompositionOperation.cs (8)
16private List<Action> _nonPrerequisiteActions; 17private List<Action> _postCompositionActions; 49public void AddNonPrerequisiteAction(Action action) 53_nonPrerequisiteActions ??= new List<Action>(); 63public void AddPostCompositionAction(Action action) 67_postCompositionActions ??= new List<Action>(); 95foreach (var action in _postCompositionActions) 107foreach (var action in currentActions)
System\Composition\Hosting\Providers\ExportFactory\ExportFactoryExportDescriptorProvider.cs (1)
54return Tuple.Create<TProduct, Action>((TProduct)CompositionOperation.Run(lifetimeContext, da), lifetimeContext.Dispose);
System\Composition\Hosting\Providers\ExportFactory\ExportFactoryWithMetadataExportDescriptorProvider.cs (1)
58return Tuple.Create<TProduct, Action>((TProduct)CompositionOperation.Run(lifetimeContext, dsc.Activator), lifetimeContext.Dispose);
System.Composition.Runtime (6)
System\Composition\ExportFactoryOfT.cs (3)
12private readonly Func<Tuple<T, Action>> _exportLifetimeContextCreator; 18public ExportFactory(Func<Tuple<T, Action>> exportCreator) 29Tuple<T, Action> untypedLifetimeContext = _exportLifetimeContextCreator.Invoke();
System\Composition\ExportFactoryOfTTMetadata.cs (1)
18public ExportFactory(Func<Tuple<T, Action>> exportCreator, TMetadata metadata)
System\Composition\ExportOfT.cs (2)
13private readonly Action _disposeAction; 20public Export(T value, Action disposeAction)
System.Core (1)
System.Core.cs (1)
11[assembly: System.Runtime.CompilerServices.TypeForwardedTo(typeof(System.Action))]
System.Diagnostics.DiagnosticSource (6)
System\Diagnostics\Metrics\AggregationManager.cs (6)
43private readonly Action _initialInstrumentEnumerationComplete; 45private readonly Action _timeSeriesLimitReached; 46private readonly Action _histogramLimitReached; 62Action initialInstrumentEnumerationComplete, 64Action timeSeriesLimitReached, 65Action histogramLimitReached,
System.Drawing.Common.Tests (16)
System\Drawing\ImageTests.cs (1)
690Action action = () => Image.FromStream(stream);
System\Drawing\Imaging\Effects\EffectsTests.cs (15)
43Action action = () => _ = new BlackSaturationCurveEffect(CurveChannel.All, blackPoint); 69Action action = () => _ = new WhiteSaturationCurveEffect(CurveChannel.All, whitePoint); 92Action action = () => _ = new BlurEffect(radius, expandEdge); 118Action action = () => _ = new BrightnessContrastEffect(brightnessLevel, contrastLevel); 146Action action = () => _ = new ColorBalanceEffect(cyanRed, magentaGreen, yellowBlue); 172Action action = () => _ = new LevelsEffect(highlight, midtone, shadow); 223Action action = () => 263Action action = () => _ = new ContrastCurveEffect(CurveChannel.All, contrast); 283Action action = () => _ = new DensityCurveEffect(CurveChannel.All, density); 303Action action = () => _ = new ExposureCurveEffect(CurveChannel.All, exposure); 323Action action = () => _ = new HighlightCurveEffect(CurveChannel.All, highlight); 343Action action = () => _ = new MidtoneCurveEffect(CurveChannel.All, midtone); 363Action action = () => _ = new ShadowCurveEffect(CurveChannel.All, shadow); 384Action action = () => _ = new SharpenEffect(radius, amount); 406Action action = () => _ = new TintEffect(hue, amount);
System.Linq.Expressions (4)
System\Linq\Expressions\Compiler\DelegateHelpers.Generated.cs (1)
238return typeof(Action);
System\Linq\Expressions\Interpreter\CallInstruction.Generated.cs (3)
219private readonly Action _target; 226_target = (Action)target.CreateDelegate(typeof(Action));
System.Net.WebClient (7)
src\libraries\Common\src\System\Threading\Tasks\RendezvousAwaitable.cs (7)
18private static readonly Action s_completionSentinel = static () => Debug.Fail("Completion sentinel should never be invoked"); 24private Action? _continuation; 44Action? c = Volatile.Read(ref _continuation); 106Action? c = _continuation ?? Interlocked.CompareExchange(ref _continuation, s_completionSentinel, null); 123public void OnCompleted(Action continuation) 127Action? c = _continuation ?? Interlocked.CompareExchange(ref _continuation, continuation, null); 136public void UnsafeOnCompleted(Action continuation) => OnCompleted(continuation);
System.Private.CoreLib (93)
src\libraries\System.Private.CoreLib\src\System\Runtime\CompilerServices\AsyncMethodBuilderCore.cs (10)
111internal static Action CreateContinuationWrapper(Action continuation, Action<Action, Task> invokeAction, Task innerTask) => 116internal static Action TryGetStateMachineForDebugger(Action action) // debugger depends on this exact name/signature 125internal static Task? TryGetContinuationTask(Action continuation) => 140private readonly Action<Action, Task> _invokeAction; // This wrapper is an action that wraps another action, this is that Action. 141internal readonly Action _continuation; // This is continuation which will happen after m_invokeAction (and is probably a ContinuationWrapper). SOS DumpAsync command depends on this name. 144internal ContinuationWrapper(Action continuation, Action<Action, Task> invokeAction, Task innerTask)
src\libraries\System.Private.CoreLib\src\System\Runtime\CompilerServices\AsyncTaskMethodBuilderT.cs (2)
329public Action MoveNextAction => (Action)(m_action ??= new Action(MoveNext));
src\libraries\System.Private.CoreLib\src\System\Runtime\CompilerServices\ConfiguredValueTaskAwaitable.cs (4)
52public void OnCompleted(Action continuation) 74public void UnsafeOnCompleted(Action continuation) 157public void OnCompleted(Action continuation) 179public void UnsafeOnCompleted(Action continuation)
src\libraries\System.Private.CoreLib\src\System\Runtime\CompilerServices\IAsyncStateMachineBox.cs (1)
18Action MoveNextAction { get; }
src\libraries\System.Private.CoreLib\src\System\Runtime\CompilerServices\INotifyCompletion.cs (2)
21void OnCompleted(Action continuation); 33void UnsafeOnCompleted(Action continuation);
src\libraries\System.Private.CoreLib\src\System\Runtime\CompilerServices\PoolingAsyncValueTaskMethodBuilderT.cs (2)
240protected Action? _moveNextAction; 396public Action MoveNextAction => _moveNextAction ??= new Action(MoveNext);
src\libraries\System.Private.CoreLib\src\System\Runtime\CompilerServices\TaskAwaiter.cs (11)
46public void OnCompleted(Action continuation) 56public void UnsafeOnCompleted(Action continuation) 174internal static void OnCompletedInternal(Task task, Action continuation, bool continueOnCapturedContext, bool flowExecutionContext) 215private static Action OutputWaitEtwEvents(Task task, Action continuation) 312public void OnCompleted(Action continuation) 322public void UnsafeOnCompleted(Action continuation) 410public void OnCompleted(Action continuation) 420public void UnsafeOnCompleted(Action continuation) 492public void OnCompleted(Action continuation) 502public void UnsafeOnCompleted(Action continuation)
src\libraries\System.Private.CoreLib\src\System\Runtime\CompilerServices\ValueTaskAwaiter.cs (6)
14/// <summary>Shim used to invoke an <see cref="Action"/> passed as the state argument to a <see cref="Action{Object}"/>.</summary> 17if (state is Action action) 47public void OnCompleted(Action continuation) 67public void UnsafeOnCompleted(Action continuation) 129public void OnCompleted(Action continuation) 149public void UnsafeOnCompleted(Action continuation)
src\libraries\System.Private.CoreLib\src\System\Runtime\CompilerServices\YieldAwaitable.cs (6)
55public void OnCompleted(Action continuation) 63public void UnsafeOnCompleted(Action continuation) 72private static void QueueContinuation(Action continuation, bool flowContext) 148private static Action OutputCorrelationEtwEvent(Action continuation) 188private static void RunAction(object? state) { ((Action)state!)(); }
src\libraries\System.Private.CoreLib\src\System\Threading\CancellationToken.cs (3)
133public CancellationTokenRegistration Register(Action callback) => Register(callback, useSynchronizationContext: false); 157public CancellationTokenRegistration Register(Action callback, bool useSynchronizationContext) 161(Action<object?>)(static obj => ((Action)obj!)()),
src\libraries\System.Private.CoreLib\src\System\Threading\LowLevelLifoSemaphore.cs (2)
20private readonly Action _onWait; 24public LowLevelLifoSemaphore(int initialSignalCount, int maximumSignalCount, int spinCount, Action onWait)
src\libraries\System.Private.CoreLib\src\System\Threading\Tasks\Task.cs (12)
353public Task(Action action) 368public Task(Action action, CancellationToken cancellationToken) 388public Task(Action action, TaskCreationOptions creationOptions) 412public Task(Action action, CancellationToken cancellationToken, TaskCreationOptions creationOptions) 2394if (m_action is Action action) 2485Action continuationAction, bool continueOnCapturedContext, bool flowExecutionContext) 3479case Action action: 3553case Action action: 3586case Action action: 5525public static Task Run(Action action) 5543public static Task Run(Action action, CancellationToken cancellationToken) 7082if (continuationObject is Action singleAction)
src\libraries\System.Private.CoreLib\src\System\Threading\Tasks\TaskAsyncEnumerableExtensions.ToBlockingEnumerable.cs (1)
75private readonly Action _onCompleted;
src\libraries\System.Private.CoreLib\src\System\Threading\Tasks\TaskContinuation.cs (14)
369Debug.Assert(state is Action); 370((Action)state)(); 382SynchronizationContext context, Action action, bool flowExecutionContext) : 432private static Action GetActionLogDelegate(int continuationId, Action action) 463TaskScheduler scheduler, Action action, bool flowExecutionContext) : 497((Action)state!)(); 525protected readonly Action m_action; 532internal AwaitTaskContinuation(Action action, bool flowExecutionContext) 669Debug.Assert(state is Action); 670((Action)state)(); 672private static readonly Action<Action> s_invokeAction = (action) => action(); 727internal static void RunOrScheduleAction(Action action, bool allowInlining) 810internal static void UnsafeScheduleAction(Action action, Task? task)
src\libraries\System.Private.CoreLib\src\System\Threading\Tasks\TaskFactory.cs (4)
276public Task StartNew(Action action) 301public Task StartNew(Action action, CancellationToken cancellationToken) 329public Task StartNew(Action action, TaskCreationOptions creationOptions) 368public Task StartNew(Action action, CancellationToken cancellationToken, TaskCreationOptions creationOptions, TaskScheduler scheduler)
src\System\GC.CoreCLR.cs (7)
581public Action Notification { get; } 583public MemoryLoadChangeNotification(float lowMemoryPercent, float highMemoryPercent, Action notification) 656internal static void RegisterMemoryLoadChangeNotification(float lowMemoryPercent, float highMemoryPercent, Action notification) 684public GCHandle<Action> action; 711public static unsafe void RegisterNoGCRegionCallback(long totalSize, Action callback) 720pWorkItem->action = new GCHandle<Action>(callback); 772internal static void UnregisterMemoryLoadChangeNotification(Action notification)
src\System\Runtime\CompilerServices\AsyncHelpers.CoreCLR.cs (5)
208static abstract Action GetContinuationAction(T task); 250public static Action GetContinuationAction(ThunkTask<T> task) => (Action)task.m_action!; 322public static Action GetContinuationAction(ThunkTask task) => (Action)task.m_action!;
src\System\Runtime\ControlledExecution.CoreCLR.cs (1)
43public static void Run(Action action, CancellationToken cancellationToken)
System.Private.Windows.Core.Tests (28)
System\Private\Windows\Ole\BinaryFormatUtilitiesTests.cs (21)
261Action action = () => BinaryFormatUtilities.TryReadObjectFromStream(stream, in request, out Array? _); 350Action writer = () => WriteObjectToStream(value); 351Action reader = () => TryReadObjectFromStream(out object? _); 378Action writer = () => WriteObjectToStream(value, restrictSerialization: true); 418Action read = () => TryReadObjectFromStream<List<object>>(ObjectListResolver, out _); 465Action action = () => BinaryFormatUtilities.TryReadObjectFromStream(stream, ref request, out BaseClass? _); 485Action action = () => BinaryFormatUtilities.TryReadObjectFromStream(stream, ref request, out BaseClass? result); 524Action action = () => BinaryFormatUtilities.TryReadObjectFromStream(stream, ref request, out MyStruct? result); 557Action action = () => BinaryFormatUtilities.TryReadObjectFromStream(stream, ref request, out int? result).Should().BeTrue(); 610Action action = () => BinaryFormatUtilities.TryReadObjectFromStream(stream, ref request, out float result); 650Action read = () => ReadPredefinedObjectFromStream<int?[]>(NotSupportedResolver, out _); 665Action action = () => TryReadObjectFromStream<int?[]>(NotSupportedResolver, out _); 686Action action = () => ReadObjectFromStream<uint[,]>(restrictDeserialization, NotSupportedResolver, out _); 776Action read = () => TryReadObjectFromStream<TestData>(InvalidResolver, out _); 790Action action = () => RoundTripOfType<TestDataBase.InnerData>(value, resolver: null, out var result); 802Action action = () => RoundTripOfType<TestDataBase.InnerData>(value, resolver: null, out var result); 832Action action = () => BinaryFormatUtilities.TryReadObjectFromStream(stream, in request, out MyClass1? result); 879Action read = () => ReadObjectFromStream<MyClass1>(restrictDeserialization, resolver: null, out _); 893Action read = () => ReadObjectFromStream<MyClass1>(restrictDeserialization, resolver: null, out _); 917Action read = () => ReadObjectFromStream<MyClass1>(restrictDeserialization: true, MyClass1.MyExactMatchResolver, out _); 930Action read = () => ReadObjectFromStream<MyClass1>(restrictDeserialization: true, MyClass1.MyExactMatchResolver, out _);
System\Private\Windows\Ole\ClipboardCoreTests.cs (4)
339Action action = () => ClipboardCore.SetData(new DataObject(format!, "data"), copy: true); 346Action action = () => ClipboardCore.SetFileDropList(null!); 353Action action = static () => ClipboardCore.SetFileDropList([]); 366Action action = () => ClipboardCore.SetFileDropList(filePaths);
System\Private\Windows\Ole\TypeBinderTests.cs (3)
38Action action = () => binder.BindToType(type.Assembly.FullName!, type.FullName!).Should().Be(type); 58Action action = () => binder.BindToType(type.Assembly.FullName!, type.FullName!).Should().Be(type); 101Action action = () => binder.BindToType(type.Assembly.FullName!, type.FullName!);
System.Runtime (1)
artifacts\obj\System.Runtime\Debug\net10.0\System.Runtime.Forwards.cs (1)
10[assembly: System.Runtime.CompilerServices.TypeForwardedTo(typeof(System.Action))]
System.Runtime.InteropServices.JavaScript (2)
artifacts\obj\System.Runtime.InteropServices.JavaScript\Debug\net10.0\System.Runtime.InteropServices.JavaScript.notsupported.cs (2)
282public void ToManaged(out Action? value) { throw new System.PlatformNotSupportedException(System.SR.SystemRuntimeInteropServicesJavaScript_PlatformNotSupported); } 283public void ToJS(Action? value) { throw new System.PlatformNotSupportedException(System.SR.SystemRuntimeInteropServicesJavaScript_PlatformNotSupported); }
System.Security.Principal.Windows (1)
artifacts\obj\System.Security.Principal.Windows\Debug\net10.0\System.Security.Principal.Windows.notsupported.cs (1)
268public static void RunImpersonated(Microsoft.Win32.SafeHandles.SafeAccessTokenHandle safeAccessTokenHandle, System.Action action) { throw new System.PlatformNotSupportedException(System.SR.PlatformNotSupported_Principal); }
System.ServiceModel.Federation (2)
System\Runtime\OperationWithTimeoutAsyncResult.cs (2)
62private Action _beforePrepareAsyncCompletionAction; 257protected void SetBeforePrepareAsyncCompletionAction(Action beforePrepareAsyncCompletionAction)
System.ServiceModel.Primitives (24)
Internals\System\Runtime\AsyncResult.cs (2)
20private Action _beforePrepareAsyncCompletionAction; 219protected void SetBeforePrepareAsyncCompletionAction(Action beforePrepareAsyncCompletionAction)
Internals\System\Runtime\InputQueue.cs (13)
374public void EnqueueAndDispatch(T item, Action dequeuedCallback) 379public void EnqueueAndDispatch(Exception exception, Action dequeuedCallback, bool canDispatchOnThisThread) 385public void EnqueueAndDispatch(T item, Action dequeuedCallback, bool canDispatchOnThisThread) 391public bool EnqueueWithoutDispatch(T item, Action dequeuedCallback) 397public bool EnqueueWithoutDispatch(Exception exception, Action dequeuedCallback) 648private static void InvokeDequeuedCallback(Action dequeuedCallback) 656private static void InvokeDequeuedCallbackLater(Action dequeuedCallback) 678Action dequeuedCallback = (Action)state; 854public Item(T value, Action dequeuedCallback) 859public Item(Exception exception, Action dequeuedCallback) 864private Item(T value, Exception exception, Action dequeuedCallback) 871public Action DequeuedCallback { get; }
Internals\System\Runtime\IOThreadScheduler.cs (1)
439private readonly Action _postDelegate;
Internals\System\Runtime\TaskHelpers.cs (1)
450public void OnCompleted(Action continuation)
System\ServiceModel\Channels\DeliveryStrategy.cs (1)
28public Action DequeueCallback { get; set; }
System\ServiceModel\Channels\InputQueueChannel.cs (5)
37public void EnqueueAndDispatch(TDisposable item, Action dequeuedCallback, bool canDispatchOnThisThread) 45public void EnqueueAndDispatch(Exception exception, Action dequeuedCallback, bool canDispatchOnThisThread) 51public void EnqueueAndDispatch(TDisposable item, Action dequeuedCallback) 59public bool EnqueueWithoutDispatch(Exception exception, Action dequeuedCallback) 65public bool EnqueueWithoutDispatch(TDisposable item, Action dequeuedCallback)
System\ServiceModel\Dispatcher\DuplexChannelBinder.cs (1)
1058private Action _messageDequeuedCallback;
System.Text.RegularExpressions (1)
System\Text\RegularExpressions\RegexCompiler.cs (1)
5320void EmitStackPush(Action load)
System.Threading.RateLimiting (7)
System\Threading\RateLimiting\ConcurrencyLimiter.cs (2)
225internal event Action? ReleasePreHook; 226internal event Action? ReleasePostHook;
System\Threading\RateLimiting\TimerAwaitable.cs (5)
16private Action? _callback; 17private static readonly Action _callbackCompleted = () => { }; 89Action? continuation = Interlocked.Exchange(ref _callback, _callbackCompleted); 93public void OnCompleted(Action continuation) 102public void UnsafeOnCompleted(Action continuation)
System.Threading.Tasks.Dataflow (10)
Blocks\BatchedJoinBlock.cs (8)
73Action createBatchAction = () => 321Action createBatchAction = () => 673Action batchSizeReachedAction, Action allTargetsDecliningAction, 674Action<Exception> exceptionAction, Action completionAction) 726internal readonly Action _batchSizeReachedAction; 728internal readonly Action _allTargetsDecliningPermanentlyAction; 732internal readonly Action _completionAction;
Blocks\JoinBlock.cs (2)
1025Action joinFilledAction, Action<Exception> exceptionAction, 1052internal readonly Action _joinFilledAction;
System.Threading.Tasks.Parallel (6)
System\Threading\Tasks\Parallel.cs (6)
144/// <param name="actions">An array of <see cref="System.Action">Actions</see> to execute.</param> 158public static void Invoke(params Action[] actions) 168/// <param name="actions">An array of <see cref="System.Action">Actions</see> to execute.</param> 191public static void Invoke(ParallelOptions parallelOptions, params Action[] actions) 206Action[] actionsCopy = new Action[actions.Length];
System.Windows.Controls.Ribbon (16)
Microsoft\Windows\Controls\KeyTipService.cs (3)
976(Action)delegate() 1195(Action)delegate() 1449(Action)delegate()
Microsoft\Windows\Controls\Ribbon\Primitives\RibbonGroupsPanel.cs (1)
99(Action)delegate()
Microsoft\Windows\Controls\Ribbon\Primitives\RibbonQuickAccessToolBarPanel.cs (1)
245Dispatcher.BeginInvoke((Action)delegate()
Microsoft\Windows\Controls\Ribbon\Ribbon.cs (1)
1730(Action)delegate()
Microsoft\Windows\Controls\Ribbon\RibbonComboBox.cs (2)
882Dispatcher.BeginInvoke((Action)delegate() 1231(Action)delegate()
Microsoft\Windows\Controls\Ribbon\RibbonContextMenu.cs (2)
143(Action)delegate() 214(Action)delegate()
Microsoft\Windows\Controls\Ribbon\RibbonHelper.cs (5)
1182(Action)delegate() 1290(Action)delegate() 1341(Action)delegate() 2872(Action)delegate() 2889submenuScrollViewer?.Dispatcher.BeginInvoke((Action)delegate ()
Microsoft\Windows\Controls\Ribbon\RibbonMenuItem.cs (1)
1002(Action)delegate()
System.Windows.Forms (8)
System\Windows\Forms\Application.MarshallingControl.cs (1)
12/// on the correct thread via <see cref="Control.Invoke(Action)"/>.
System\Windows\Forms\Control.cs (4)
4353/// An <see cref="IAsyncResult"/> that represents the result of the <see cref="BeginInvoke(Action)"/> operation. 4356public IAsyncResult BeginInvoke(Action method) => BeginInvoke(method, null); 6029public void Invoke(Action method) 6170else if (tme._method is Action action)
System\Windows\Forms\Control_InvokeAsync.cs (3)
50public async Task InvokeAsync(Action callback, CancellationToken cancellationToken = default) 253/// For synchronous operations, use <see cref="InvokeAsync(Action, CancellationToken)"/> or 358/// For synchronous operations, use <see cref="InvokeAsync(Action, CancellationToken)"/> or
System.Windows.Forms.Design (1)
System\Windows\Forms\Design\CommandSet.cs (1)
409internal static bool ExecuteSafely(Action action, bool throwOnException)
System.Windows.Forms.Design.Tests (60)
ButtonBaseDesignerTests.cs (1)
41Action action = () => buttonBaseDesigner.InitializeNewComponent((IDictionary?)defaultValues);
ControlDesignerTests.cs (13)
31Action action1 = () => 36Action action2 = () => 41Action action3 = () => controlDesigner.GetParentComponentProperty(); 108Action action = () => 131Action action = () => _designer.EnableDragDropMethod(val); 138Action action = () => 152Action action = () => 165Action action = _designer.OnSetComponentDefaults; 173Action action = () => _designer.OnContextMenuMethod(0, 0); 180Action action = _designer.OnCreateHandleMethod; 187Action action = () => 255Action action = () => _designer.GetGlyphs(GlyphSelectionType.SelectedPrimary); 361Action action = () => _designer.InitializeExistingComponent(defaultValues);
System\Windows\Forms\Design\AxImporterTests.cs (1)
15Action action = () => new AxImporter(options);
System\Windows\Forms\Design\ComponentDocumentDesignerTests.cs (1)
13Action action = () => designer.Initialize(timer);
System\Windows\Forms\Design\ControlDesigner.DesignerControlCollectionTests.cs (1)
29Action action = () => new ControlDesigner.DesignerControlCollection(null!);
System\Windows\Forms\Design\CustomMenuItemCollectionTests.cs (1)
46Action action = () => _collection.AddRange(items);
System\Windows\Forms\Design\DataSourceListEditorTests.cs (1)
28Action action = () =>
System\Windows\Forms\Design\DesignBindingValueUIHandlerTests.cs (2)
25Action action = () => bitmap.GetPixel(0, 0); 32Action action = _handler.Dispose;
System\Windows\Forms\Design\DesignerUtilsTests.cs (3)
419Action action = () => DesignerUtils.ApplyListViewThemeStyles(null!); 435Action action = () => DesignerUtils.ApplyTreeViewThemeStyles(null!); 581Action action = () => DesignerUtils.GetTextBaseline(null!, ContentAlignment.TopLeft);
System\Windows\Forms\Design\FormatStringDialogTests.cs (4)
22Action action = () => 49Action action = () => _formatStringDialog.DataGridViewCellStyle = new(); 60Action action = () => 71Action action = FormatStringDialog.End;
System\Windows\Forms\Design\ImageCollectionCodeDomSerializerTests.cs (3)
24Action act = () => _serializer.Deserialize(null!, new object()); 31Action act = () => _serializer.Deserialize(new DesignerSerializationManager(), null!); 38Action act = () => _serializer.Serialize(new DesignerSerializationManager(), null!);
System\Windows\Forms\Design\ImageIndexEditorTests.cs (1)
37Action action = () => _editor.PaintValue(paintValueEventArgs);
System\Windows\Forms\Design\ImageListDesignerOriginalImageCollectionTests.cs (3)
38Action action = () => new ImageListDesigner.OriginalImageCollection(null!); 48Action action = () => { var image = _originalImageCollection[1]; }; 58Action action = () => _originalImageCollection[1] = new ImageListImage(_image);
System\Windows\Forms\Design\LinkAreaEditor.LinkAreaUITests.cs (1)
109Action action = () => _linkAreaUI.Start(null);
System\Windows\Forms\Design\ListControlStringCollectionEditorTests.cs (1)
65ArgumentException exception = ((Action)(() => editor.EditValue(context.Object, provider, value))).Should().Throw<ArgumentException>().Which;
System\Windows\Forms\Design\ListViewGroupCollectionEditorTests.cs (1)
65Action action = () => _mockEditor.Object.TestAccessor().Dynamic.CreateInstance(typeof(ListViewGroup));
System\Windows\Forms\Design\NotifyIconDesignerActionListTests.cs (1)
34Action act = _actionList.ChooseIcon;
System\Windows\Forms\Design\ParentControlDesignerTests.cs (1)
200Action action = () => _designer.TestAccessor().Dynamic.GridSize = new Size(1, 1);
System\Windows\Forms\Design\RichTextBoxActionListTests.cs (1)
11Action action = () => new RichTextBoxActionList(null!);
System\Windows\Forms\Design\SelectionUIHandlerTests.cs (5)
169Action act = _selectionUIHandlerMock.Object.SetCursor; 179Action act = () => _selectionUIHandlerMock.Object.OleDragEnter(dragEventArgs); 188Action act = () => _selectionUIHandlerMock.Object.OleDragDrop(dragEventArgs); 197Action act = () => _selectionUIHandlerMock.Object.OleDragOver(dragEventArgs); 205Action act = _selectionUIHandlerMock.Object.OleDragLeave;
System\Windows\Forms\Design\StandardCommandToolStripMenuItemTests.cs (1)
79Action action = _item.PerformClick;
System\Windows\Forms\Design\StandardMenuStripVerbTests.cs (2)
120Action action = () => new StandardMenuStripVerb(null); 127Action action = () =>
System\Windows\Forms\Design\StatusCommandUITests.cs (1)
118private void TestSetStatusInformation(Action action, Rectangle expectedRectangle)
System\Windows\Forms\Design\TableLayoutPanelDesignerTests.cs (2)
41Action rowCountAct = () => _designer.RowCount = 0; 54Action columnCountAct = () => _designer.ColumnCount = 0;
System\Windows\Forms\Design\ToolStripAdornerWindowServiceTests.cs (3)
81Action action = _service.Invalidate; 89Action action = () => _service.Invalidate(region); 128Action action = () => _service.ProcessPaintMessage(paintRect);
System\Windows\Forms\Design\ToolStripCollectionEditorTests.cs (1)
21Action act = () => _editor.TestAccessor().Dynamic.CreateCollectionForm();
System\Windows\Forms\Design\ToolStripDesignerUtilsTests.cs (1)
153Action act = () => ToolStripDesignerUtils.InvalidateSelection(originalSelComps, nextSelection, mockServiceProvider.Object, false);
System\Windows\Forms\Design\ToolStripEditorManagerTests.cs (3)
79Action action = () => _editorManager.ActivateEditor(null); 89Action action = () => _editorManager.ActivateEditor(_toolStripItem); 160Action action = ToolStripEditorManager.CloseManager;
System.Windows.Forms.Interop.Tests (1)
PropertyGridTests.cs (1)
79private unsafe void ExecuteWithActivationContext(string applicationManifest, Action action)
System.Windows.Forms.Primitives (3)
Windows\Win32\PInvoke.SendMessageCallback.cs (3)
14Action callback, 29Action action = (Action)gcHandle.Target!;
System.Windows.Forms.Primitives.TestUtilities (15)
Extensions\AssertExtensions.cs (15)
27public static void Throws<T>(Action action, string expectedMessage) 33public static void ThrowsContains<T>(Action action, string expectedMessageContent) 39public static T Throws<T>(string netCoreParamName, string netFxParamName, Action action) 76public static T Throws<T>(string expectedParamName, Action action) 86public static T Throws<T>(Action action) 148public static void Throws<TNetCoreExceptionType, TNetFxExceptionType>(string expectedParamName, Action action) 172public static Exception Throws<TNetCoreExceptionType, TNetFxExceptionType>(Action action) 179public static Exception Throws(Type netCoreExceptionType, Type netFxExceptionType, Action action) 191public static void Throws<TNetCoreExceptionType, TNetFxExceptionType>(string netCoreParamName, string netFxParamName, Action action) 205public static void ThrowsAny(Type firstExceptionType, Type secondExceptionType, Action action) 210private static void ThrowsAnyInternal(Action action, params Type[] exceptionTypes) 228public static void ThrowsAny<TFirstExceptionType, TSecondExceptionType>(Action action) 235public static void ThrowsAny<TFirstExceptionType, TSecondExceptionType, TThirdExceptionType>(Action action) 243public static void ThrowsIf<T>(bool condition, Action action) 256public static void Canceled(CancellationToken cancellationToken, Action testCode)
System.Windows.Forms.Tests (279)
CheckedListBoxTests.cs (2)
854Action actAdd = () => checkedListBox.DrawItem += handler; 855Action actRemove = () => checkedListBox.DrawItem -= handler;
ExceptionHandlingTests.cs (1)
15Action action = () =>
LinkLabelTests.cs (1)
64Action act = () => _linkLabel.LinkArea = new LinkArea(start, length);
MaskedTextBoxTests.cs (3)
805Action act = () => _maskedTextBox.PromptChar = '\0'; 808Action act2 = () => _maskedTextBox.PasswordChar = '\t'; 816Action act = () => _maskedTextBox.PasswordChar = 'A';
NumericUpDownTests.cs (1)
304Action act = () => upDown.Increment = -1;
System\Windows\Forms\AbstractButtonBaseTests.cs (1)
72Action act = () => overChangeRectangle = control.OverChangeRectangle;
System\Windows\Forms\AccessibleObjects\ButtonBase.ButtonBaseAccessibleObjectTests.cs (1)
271public Action PerformClickAction { get; set; }
System\Windows\Forms\AccessibleObjects\DataGridViewTopLeftHeaderCellAccessibleObjectTests.cs (4)
86Action action = () => _ = accessibleObject.DefaultAction; 95Action action = () => _ = accessibleObject.State; 172Action action = () => _ = accessibleObject.Name; 194Action action = () => accessibleObject.Navigate(AccessibleNavigation.Next);
System\Windows\Forms\AccessibleObjects\LabelAccessibleObjectTests.cs (1)
163Action action = () => new LabelAccessibleObject(null);
System\Windows\Forms\AccessibleObjects\ListBox.ListBoxItemAccessibleObjectTests.cs (1)
194Action action = () => listBoxItemAccessibleObject.Select(flags);
System\Windows\Forms\AccessibleObjects\ListViewGroup.ListViewGroupAccessibleObjectTests.cs (1)
23Action action = () => new ListViewGroupAccessibleObject(null, list, false);
System\Windows\Forms\AccessibleObjects\MonthCalendar.CalendarButtonAccessibleObjectTests.cs (2)
108Action combinedAction = () => 126Action action = () => buttonAccessibleObject.TestAccessor().Dynamic.RaiseMouseClick();
System\Windows\Forms\ButtonBaseTests.cs (1)
9264public Action PerformClickAction { get; set; }
System\Windows\Forms\CheckBoxPopupAdapterTests.cs (5)
26Action action = () => adapter.PaintUp(e, state); 44Action action = () => adapter.PaintOver(e, state); 62Action action = () => adapter.PaintDown(e, state); 76Action action = () => adapter.TestAccessor().Dynamic.Layout(e); 87Action action = () => adapter.TestAccessor().Dynamic.CreateButtonAdapter();
System\Windows\Forms\CheckedListBox.CheckedIndexCollectionTests.cs (1)
48((Action)(() => ((IList)_collection)[0] = 1)).Should().Throw<NotSupportedException>();
System\Windows\Forms\CheckedListBox.CheckedItemCollectionTests.cs (1)
42((Action)(() => ((IList)_collection)[0] = 1)).Should().Throw<NotSupportedException>();
System\Windows\Forms\ClipboardTests.cs (39)
43Action action = () => Clipboard.ContainsText(format); 63Action action = () => Clipboard.GetText(format); 94Action action = () => Clipboard.SetAudio((byte[])null!); 126Action action = () => Clipboard.SetAudio((Stream)null!); 133Action action = () => Clipboard.SetData("MyData", data: null!); 152Action action = () => Clipboard.SetData(format!, "data"); 161Action action = () => Clipboard.SetData("MyData", data: null!); 243public static TheoryData<Action> SetDataObject_Null_TheoryData => 252public void SetDataObject_NullData_ThrowsArgumentNullException(Action action) 260Action action = () => Clipboard.SetDataObject(new object(), copy: true, retryTimes: -1, retryDelay: 0); 267Action action = () => Clipboard.SetDataObject(new object(), copy: true, retryTimes: 10, retryDelay: -1); 271public static TheoryData<Action> NotAnStaTheoryData => 273(Action)Clipboard.Clear, 274(Action)(() => Clipboard.SetAudio(Array.Empty<byte>())), 275(Action)(() => Clipboard.SetAudio(new MemoryStream())), 276(Action)(() => Clipboard.SetDataObject(new DataObject())), 277(Action)(() => Clipboard.SetDataObject(new DataObject(), copy: true)), 278(Action)(() => Clipboard.SetDataObject(new DataObject(), copy: true, retryTimes: 10, retryDelay: 0)), 279(Action)(() => Clipboard.SetFileDropList(["filePath"])), 280(Action)(() => Clipboard.SetText("text")), 281(Action)(() => Clipboard.SetText("text", TextDataFormat.Text)) 286public void NotSta_ThrowsThreadStateException(Action action) 297Action action = () => Clipboard.SetImage(bitmap); 322Action action = () => Clipboard.SetFileDropList(null!); 329Action action = static () => Clipboard.SetFileDropList([]); 342Action action = () => Clipboard.SetFileDropList(filePaths); 404Action action = () => Clipboard.SetImage(null!); 421Action action = () => Clipboard.SetText(text); 431Action action = () => Clipboard.SetText("text", format); 710Action tryGetData = () => Clipboard.TryGetData(format, out object? data); 732Action tryGetData = () => Clipboard.TryGetData(format, out object? data); 744Action tryGetData = () => Clipboard.TryGetData(format, out object? data); 807Action action = () => Clipboard.SetDataAsJson(format!, 1); 815Action action = () => Clipboard.SetDataAsJson(format, new DataObject()); 817Action clipboardSet2 = () => Clipboard.SetDataAsJson(format, new DerivedDataObject()); 979Action a1 = () => JsonSerializer.Deserialize<Font>(serialized); 1024Action tryGetData = () => received.TryGetData(format, out byte[]? _); 1080Action clipboardSet = () => Clipboard.SetDataAsJson<string>("format", null!); 1286Action tryGetData = () => received.TryGetData(format, out SerializableTestData? result);
System\Windows\Forms\ControlTests.Methods.cs (6)
1819Action dragDrop = () => control.DoDragDrop(null, DragDropEffects.All); 1827Action dragDrop = () => control.DoDragDropAsJson<string>(null, DragDropEffects.Copy); 3766Action method = () => 3791Action method = () => 3817Action method = () => 4133Action method = () => { };
System\Windows\Forms\DataGridViewButtonCellTests.cs (1)
195Action action = () => _dataGridViewButtonCell.TestAccessor().Dynamic.GetPreferredSize(g, null, 0, new Size(100, 100));
System\Windows\Forms\DataGridViewButtonColumnTests.cs (3)
61Action action = () => { var flatStyle = _column.FlatStyle; }; 104Action action = () => { bool useColumnTextForButtonValue = _column.UseColumnTextForButtonValue; }; 160Action action = () => _column.CellTemplate = new DataGridViewTextBoxCell();
System\Windows\Forms\DataGridViewCellConverterTests.cs (1)
35Action action = () => _converter.ConvertTo(context: null, CultureInfo.InvariantCulture, value, destinationType);
System\Windows\Forms\DataGridViewCellStyleConverterTests.cs (1)
43Action action = () => _converter.ConvertTo(null, CultureInfo.InvariantCulture, _style, typeof(int));
System\Windows\Forms\DataGridViewCellTests.ClipboardTests.cs (3)
94Action action = () => cell.GetClipboardContent(rowIndex, true, true, true, true, "format"); 112Action action = () => cell.GetClipboardContent(rowIndex, true, true, true, true, "format"); 130Action action = () => cell.GetClipboardContent(rowIndex, true, true, true, true, "format");
System\Windows\Forms\DataGridViewCellTests.cs (1)
6530Action act = () => cell.MouseClick(new DataGridViewCellMouseEventArgs(0, 0, 10, 10, new MouseEventArgs(MouseButtons.Left, 1, 10, 10, 0)));
System\Windows\Forms\DataGridViewColumnConverterTests.cs (2)
54Action action = () => _converter.ConvertTo(context: null, culture: CultureInfo.InvariantCulture, value: _column, destinationType: null!); 61Action action = () => _converter.ConvertTo(context: null, culture: CultureInfo.InvariantCulture, value: _column, destinationType: typeof(int));
System\Windows\Forms\DataGridViewComboBoxCell.ObjectCollectionTests.cs (14)
66Action action = () => _collection.Add(null!); 116Action action = () => _collection.AddRange(items); 151Action action = () => _collection[index] = "Item"; 161Action action = () => _collection[0] = null!; 194Action action = () => _collection.Contains(null!); 216Action actionNullDestination = () => _collection.CopyTo(null!, 0); 220Action actionNegativeIndex = () => _collection.CopyTo(destination, -1); 223Action actionOutOfRangeIndex = () => _collection.CopyTo(destination, 4); 234Action action = () => _collection.CopyTo(destination, 0); 273Action action = () => _collection.IndexOf(null!); 305Action actionNegativeIndex = () => _collection.Insert(-1, "Item"); 306Action actionOutOfRangeIndex = () => _collection.Insert(1, "Item"); 307Action actionNullItem = () => _collection.Insert(0, null!); 346Action action = () => _collection.RemoveAt(index);
System\Windows\Forms\DataGridViewComboBoxColumnTests.cs (2)
327var actions = new List<Action> 352foreach (var action in actions)
System\Windows\Forms\DataGridViewImageCellTests.cs (2)
222Action action = () => dataGridViewImageCell.TestAccessor().Dynamic.GetPreferredSize(g, null, 0, new Size(100, 100)); 240Action action = () => dataGridViewImageCell.TestAccessor().Dynamic.Paint(
System\Windows\Forms\DataGridViewImageColumnTests.cs (2)
30Action action = () => { var _ = _column.Description; }; 38Action action = () => _column.Description = "desc";
System\Windows\Forms\DataGridViewLinkCellTests.cs (5)
277Action action = () => dataGridView.Rows[0].Cells[0].GetContentBounds(-1); 288((Action)(() => _cell.GetErrorIconBounds(0))).Should().Throw<InvalidOperationException>(); 296Action action = () => _cell.GetErrorIconBounds(-1); 304((Action)(() => _cell.GetErrorIconBounds(0))).Should().Throw<InvalidOperationException>(); 658TargetInvocationException ex = ((Action)(() =>
System\Windows\Forms\DataGridViewLinkColumnTests.cs (1)
82Action action = () => _column.CellTemplate = cell;
System\Windows\Forms\DataGridViewTextBoxColumnTests.cs (3)
47Action action = () => _column.CellTemplate = cell; 95Action action = () => column.MaxInputLength = 100; 105Action action = () => maxInput = _column.MaxInputLength;
System\Windows\Forms\DataObjectExtensionsTests.cs (10)
16Action tryGetData1 = () => DataObjectExtensions.TryGetData<string>(dataObject: null!, out _); 18Action tryGetData2 = () => DataObjectExtensions.TryGetData<string>(dataObject: null!, DataFormats.Text, out _); 20Action tryGetData3 = () => DataObjectExtensions.TryGetData<string>(dataObject: null!, DataFormats.Dib, autoConvert: true, out _); 22Action tryGetData4 = () => DataObjectExtensions.TryGetData<string>(dataObject: null!, DataFormats.EnhancedMetafile, autoConvert: false, out _); 24Action tryGetData5 = () => DataObjectExtensions.TryGetData<string>(dataObject: null!, DataFormats.UnicodeText, Resolver, autoConvert: true, out _); 26Action tryGetData6 = () => DataObjectExtensions.TryGetData<string>(dataObject: null!, DataFormats.Serializable, Resolver, autoConvert: false, out _); 36Action tryGetData = () => dataObject.TryGetData<string>(out _); 45Action tryGetData = () => dataObject.TryGetData<string>(DataFormats.Text, out _); 55Action tryGetData = () => dataObject.TryGetData<string>(DataFormats.CommaSeparatedValue, autoConvert, out _); 65Action tryGetData = () => dataObject.TryGetData<string>(DataFormats.UnicodeText, Resolver, autoConvert, out _);
System\Windows\Forms\DataObjectTests.cs (36)
200((Action)(() => dataObject.ContainsText(format))).Should().Throw<InvalidEnumArgumentException>().WithParameterName("format"); 471Action tryGetData = () => dataObject.TryGetData(format, out string? data); 485Action tryGetData = () => wrapper.TryGetData(format, out string? data); 533Action tryGetData = () => dataObject.TryGetData(format, autoConvert, out string? data); 571Action tryGetData = () => dataObject.TryGetData(format, DataObjectOverridesTryGetDataCore.Resolver, autoConvert, out string? data); 585Action tryGetData = () => wrapper.TryGetData(format, DataObjectOverridesTryGetDataCore.Resolver, autoConvert, out string? data); 1037Action action = () => dataObject.GetText(format); 1095Action action = () => dataObject.SetAudio((byte[])null); 1153Action action = () => dataObject.SetAudio((Stream)null); 1237((Action)(() => dataObject.SetData(null))).Should().Throw<ArgumentNullException>().WithParameterName("data"); 1566((Action)(() => dataObject.SetData((string)null, new object()))).Should() 1568((Action)(() => dataObject.SetData(null, true, new object()))).Should() 1570((Action)(() => dataObject.SetData(null, false, new object()))).Should() 1572((Action)(() => dataObject.SetData((Type)null, new object()))).Should() 1582Action action = () => dataObject.SetData(format, new object()); 1596((Action)(() => dataObject.SetData(DataFormats.Dib, false, new Bitmap(10, 10)))) 1662Action action = () => dataObject.SetFileDropList(null); 1724Action action = () => dataObject.SetImage(null); 1897((Action)(() => dataObject.SetText(textData))).Should() 1899((Action)(() => dataObject.SetText(textData, TextDataFormat.Text))).Should() 1908((Action)(() => dataObject.SetText("text", format))).Should() 2011Action action = () => comDataObject.DUnadvise(connection); 2160((Action)(() => enumerator.Next(1, null, fetched))).Should().Throw<NullReferenceException>(); 2236Action action = () => enumerator.Next(1, result, fetched); 2289Action action = () => enumerator.Next(1, result, fetched); 2350((Action)(() => enumerator.Next(1, null, fetched))).Should().Throw<NullReferenceException>(); 2418((Action)(() => comDataObject.EnumFormatEtc(dwDirection))).Should().Throw<ExternalException>(); 2554((Action)(() => iComDataObject.GetDataHere(ref formatetc, ref stgMedium))).Should().Throw<ArgumentException>(); 2576((Action)(() => iComDataObject.GetDataHere(ref formatetc, ref stgMedium))).Should().Throw<ArgumentException>(); 2675((Action)(() => iComDataObject.GetDataHere(ref formatetc, ref stgMedium))).Should().Throw<ArgumentException>(); 2717((Action)(() => iComDataObject.GetDataHere(ref formatetc, ref stgMedium))).Should().Throw<COMException>() 2743((Action)(() => iComDataObject.GetDataHere(ref formatetc, ref stgMedium))).Should().Throw<COMException>() 2936Action action = () => dataObject.SetDataAsJson(format, new DataObject()); 2939Action dataObjectSet2 = () => dataObject.SetDataAsJson(format, new DerivedDataObject()); 3089Action dataObjectSet = () => dataObject.SetDataAsJson<string>(null); 3100Action action = () => dataObject.SetDataAsJson(format, 1);
System\Windows\Forms\DateTimePickerTests.cs (8)
191Action act = () => control.CalendarTitleBackColor = ColorTranslator.FromHtml(value); 213Action act = () => control.CalendarForeColor = ColorTranslator.FromHtml(value); 235Action act = () => control.CalendarTitleForeColor = ColorTranslator.FromHtml(value); 257Action act = () => control.CalendarTrailingForeColor = ColorTranslator.FromHtml(value); 279Action act = () => control.CalendarMonthBackground = ColorTranslator.FromHtml(value); 386Action act = () => _dateTimePicker.MaxDate = DateTime.Parse(value); 414Action act = () => _dateTimePicker.MinDate = DateTimePicker.MaximumDateTime.AddDays(1); 509Action act = () => _dateTimePicker.Value = DateTime.Parse(value);
System\Windows\Forms\DomainUpDownTests.cs (1)
1128Action act = () => _control.MatchIndex(null, false, 0);
System\Windows\Forms\FlatButtonAppearanceConverterTests.cs (3)
26Action action1 = () => _converter.ConvertTo(context: null, culture: null, value: null, destinationType: null!); 27Action action2 = () => _converter.ConvertTo(context: null, culture: null, value: null, destinationType: typeof(int)); 38Action action = () => _converter.GetProperties(context: null, value: button, attributes: null);
System\Windows\Forms\HtmlElementErrorEventArgsTests.cs (1)
41Action action = () => _ = args.Url;
System\Windows\Forms\LinkCollectionTests.cs (1)
53Action act = () => ((IList)_linkCollection)[0] = "InvalidLink";
System\Windows\Forms\LinkUtilitiesTests.cs (1)
41Action act = () => LinkUtilities.EnsureLinkFonts(baseFont, behavior, ref linkFont, ref hoverLinkFont);
System\Windows\Forms\ListBoxTests.cs (2)
6330Action action = () => listBox.SelectedIndex = 0; 6347Action action = () => listBox.SelectedIndex = 0;
System\Windows\Forms\ListControlTests.cs (1)
2998public Action RefreshItemsHandler { get; set; }
System\Windows\Forms\ListView.CheckedIndexCollectionTests.cs (3)
69Action act = () => _ = _collection[1]; 161Action act = method switch 192Action act = () => ilist[0] = 1;
System\Windows\Forms\ListView.CheckedListViewItemCollectionTests.cs (13)
44Action act = () => { int _ = _collection.Count; }; 68Action act = () => { var _ = _collection[0]; }; 90Action act = () => iList[0] = new ListViewItem(); 132Action act = () => { var _ = _collection["foo"]; }; 196Action act = () => _collection.Contains(item); 226Action act = () => iList.Contains(new ListViewItem()); 250Action act = () => _collection.ContainsKey("foo"); 281Action act = () => _collection.IndexOf(new ListViewItem()); 311Action act = () => _collection.IndexOfKey("foo"); 342Action act = () => iList.IndexOf(new ListViewItem()); 357Action act = methodName switch 391Action act = () => _collection.CopyTo(array, 0); 415Action act = () => _collection.GetEnumerator();
System\Windows\Forms\ListViewTests.cs (3)
4439Action action = () => listView.OnItemChecked(new ItemCheckedEventArgs(clone)); 5269Action action = () => listView.ReleaseUiaProvider(listView.InternalHandle); 5297Action action = () => listView.Items[1].ToString();
System\Windows\Forms\MonthCalendar.HitTestInfoTests.cs (1)
49Action action = () => new HitTestInfo(point, hitArea, time!.Value);
System\Windows\Forms\MonthCalendar.SelectionRangeConverterTests.cs (2)
79Action act = () => _converter.ConvertFrom(null, CultureInfo.InvariantCulture, value); 117Action act = () => _converter.ConvertTo(null, CultureInfo.InvariantCulture, _range, typeof(int));
System\Windows\Forms\MonthCalendarTests.cs (1)
4527private void ShouldSerializeProperty(Func<bool> shouldSerializeFunc, Action setPropertyAction)
System\Windows\Forms\MultiPropertyDescriptorGridEntryTests.cs (1)
201Action action = () => multiPropertyDescriptorGridEntry
System\Windows\Forms\NativeToWinFormsAdapterTests.cs (16)
51Action tryGetData = () => dataObject.TryGetData(format, out object? value); 71Action tryGetData = () => dataObject.TryGetData(format, out object? _); 93Action tryGetData = () => dataObject.TryGetData(format, out object? _); 103Action tryGetData = () => dataObject.TryGetData(format, out object? _); 117Action tryGetData = () => dataObject.TryGetData(format, out object? _); 173Action tryGetData = () => dataObject.TryGetData(format, out IList<int>? _); 188Action tryGetData = () => dataObject.TryGetData(format, out IList<int>? _); 219Action tryGetData = () => dataObject.TryGetData(format, out List<int>? _); 269Action tryGetData = () => dataObject.TryGetData(format, out TestData? _); 293Action tryGetData = () => dataObject.TryGetData(format, TestData.Resolver, autoConvert: true, out TestData? _); 305Action tryGetData = () => dataObject.TryGetData(format, TestData.Resolver, autoConvert: true, out TestData? _); 346Action tryGetData = () => dataObject.TryGetData(format, out AbstractBase? _); 356Action tryGetData = () => dataObject.TryGetData(format, out AbstractBase? _); 369Action tryGetData = () => dataObject.TryGetData(format, out AbstractBase? _); 412Action tryGetData = () => dataObject.TryGetData(format, TestData.Resolver, autoConvert: true, out AbstractBase? _); 461Action action = () => native.SetDataAsJson(format, value);
System\Windows\Forms\NumericUpDownAccelerationTests.cs (2)
18Action act = () => acceleration.Seconds = -1; 32Action act = () => acceleration.Increment = -1.0m;
System\Windows\Forms\Ole\BinaryFormatUtilitiesTests.cs (1)
128Action action = () => BinaryFormatUtilities.TryReadObjectFromStream(
System\Windows\Forms\ProgressBarRendererTest.cs (1)
73Action act = () => drawAction(graphics1, rectangle1);
System\Windows\Forms\PropertyManagerTests.cs (1)
438public Action EndEditHandler { get; set; }
System\Windows\Forms\PropertyStoreTests.cs (4)
103Action action = () => store.TryGetValue(1, out FormWindowState outValue); 113Action action = () => store.TryGetValue(1, out Color outValue); 123Action action = () => store.TryGetValue(1, out int outValue); 221Action action = () => store.AddOrRemoveValue(1, 1);
System\Windows\Forms\TabControlTests.cs (1)
5721Action act = () => control.TestAccessor().Dynamic.WmSelChange();
System\Windows\Forms\TextRendererTests.cs (4)
573public unsafe void TextRenderer_DrawText_DefaultBackground_RendersTransparent(Func<IDeviceContext, Action> func) 589public static TheoryData<Func<IDeviceContext, Action>> TextRenderer_DrawText_DefaultBackground_RendersTransparent_TestData 608public void TextRenderer_Span_ModifyString_ThrowsArgumentOutOfRange(Action action) 614public static TheoryData<Action> TextRenderer_Span_ModifyString_ThrowsArgumentOutOfRange_TestData()
System\Windows\Forms\ToolStripContainer.ToolStripContainerTypedControlCollectionTests.cs (5)
27Action act = () => collection.Add(panel); 38Action act = () => collection.Add(button); 74Action act = () => collection.Remove(control); 99Action act = () => collection.Remove(button); 115Action act = () => collection.SetChildIndexInternal(control, 0);
System\Windows\Forms\ToolStripPanel.ToolStripPanelRowCollectionTests.cs (8)
90Action action = () => _toolStripPanelRowCollection.Add(value: null!); 99Action action = () => _toolStripPanelRowCollection.AddRange(value: (ToolStripPanelRow[])null!); 127Action action = () => _toolStripPanelRowCollection.AddRange(value: (ToolStripPanelRowCollection)null!); 226Action action = () => _toolStripPanelRowCollection.RemoveAt(1); 240Action action = () => _toolStripPanelRowCollection.RemoveAt(0); 268Action action = () => _toolStripPanelRowCollection.CopyTo(array: null!, index: 0); 283Action action = () => _toolStripPanelRowCollection.CopyTo(array: array, index: 1); 302Action action = () => _toolStripPanelRowCollection.CopyTo(array: array, index: 0);
System\Windows\Forms\ToolStripProfessionalLowResolutionRendererTests.cs (3)
28Action action = () => _toolStripProfessionalLowResolutionRenderer.TestAccessor().Dynamic.OnRenderToolStripBackground(args); 41Action action = () => _toolStripProfessionalLowResolutionRenderer.TestAccessor().Dynamic.OnRenderToolStripBackground(args); 58Action action = () => _toolStripProfessionalLowResolutionRenderer.TestAccessor().Dynamic.OnRenderToolStripBorder(args);
System\Windows\Forms\ToolStripSplitButtonTests.cs (1)
324Action action = () => _toolStripSplitButton.DropDownButtonWidth = -1;
System\Windows\Forms\ToolStripSplitStackDragDropHandlerTests.cs (2)
97Action action = () => _toolStripSplitStackDragDropHandler.OnGiveFeedback(giveFeedbackEventArgs); 106Action action = () => _toolStripSplitStackDragDropHandler.OnQueryContinueDrag(queryContinueDragEventArgs);
System\Windows\Forms\TrackBarRendererTests.cs (7)
38Action a = () => drawTrack(_graphics, bounds); 53Action a = () => drawTrack(_graphics, bounds); 75Action a = () => drawThumb(_graphics, bounds, state); 106Action a = () => drawTicks(_graphics, bounds, tickCount, edgeStyle); 126Action a = () => drawTicks(_graphics, bounds, count, EdgeStyle.Raised); 132Action a = () => drawTicks(_graphics, invalidBound, 5, EdgeStyle.Raised); 163Action a = () => drawThumb(_graphics, bounds, TrackBarThumbState.Normal);
System\Windows\Forms\TreeViewTests.cs (4)
7157Action action = parent.Nodes.Clear; 7182Action action = () => parent.Nodes.Remove(secondNode); 7211Action action = () => 7265Action action = parent.Nodes.Clear;
System\Windows\Forms\UnsupportedTypesTests.cs (11)
15public static TheoryData<Action> UnsupportedControlsConstructors => 63public void UnsupportedControl_Constructor_Throws(Action action) => 85((Action)(() => new StatusBarDrawItemEventArgs(graphics, font: null!, rectangle, itemId: 0, DrawItemState.Checked, panel: null!))) 87((Action)(() => new StatusBarDrawItemEventArgs(graphics, font: null!, rectangle, itemId: 0, DrawItemState.Checked, panel: null!, foreColor: Color.Red, backColor: Color.Black))) 136((Action)(() => createFrameworkTypes.CreateMenus(button))).Should().Throw<PlatformNotSupportedException>(); 143((Action)(() => form.Menu = CreateFrameworkTypes.CreateMainMenu())).Should().Throw<PlatformNotSupportedException>(); 151((Action)(() => createFrameworkTypes.CreateDataGrid(form))).Should().Throw<PlatformNotSupportedException>(); 159((Action)(() => createFrameworkTypes.AddCustomDataTableStyle(form))).Should().Throw<PlatformNotSupportedException>(); 164((Action)(() => CreateFrameworkTypes.DataGrid_MouseUp(null, null))).Should().Throw<NullReferenceException>(); 171((Action)(() => createFrameworkTypes.CreateToolBar(form))).Should().Throw<PlatformNotSupportedException>(); 179((Action)(() => createFrameworkTypes.CreateStatusBar(form))).Should().Throw<PlatformNotSupportedException>();
System\Windows\Forms\UpDownBaseTests.cs (4)
3054public Action DownButtonAction { get; set; } 3068public Action UpButtonAction { get; set; } 3072public Action UpdateEditTextAction { get; set; } 3082public Action ValidateEditTextAction { get; set; }
System\Windows\Forms\WebBrowserUriTypeConverterTests.cs (1)
50Action action = () => _converter.ConvertFrom(null, CultureInfo.InvariantCulture, "http://inv@lid uri");
TextBoxTests.cs (2)
268Action act = () => control.AutoCompleteMode = value; 293Action act = () => control.AutoCompleteSource = source;
System.Windows.Forms.TestUtilities (2)
PropertyGridInternal\SubPropertyGrid.cs (2)
43public void PopupEditorAndClose(Action? onClosingAction = null) 102((Action)GCHandle.FromIntPtr(m.LParamInternal).Target!)();
System.Windows.Forms.UI.IntegrationTests (2)
PropertyGridTests.cs (2)
100Action act = _propertyGrid.Refresh; 316Action act = () => _propertyGrid.SelectedObjects = objects;
System.Windows.Input.Manipulations (1)
System\Windows\Input\Manipulations\InertiaParameters2D.cs (1)
27internal void ProtectedChangeProperty(Func<bool> isEqual, Action setNewValue, string paramName)
System.Windows.Presentation (6)
System\Windows\Threading\DispatcherExtensions.cs (6)
28public static DispatcherOperation BeginInvoke(this Dispatcher dispatcher, Action action) 55public static DispatcherOperation BeginInvoke(this Dispatcher dispatcher, Action action, DispatcherPriority priority) 74public static void Invoke(this Dispatcher dispatcher, Action action) 97public static void Invoke(this Dispatcher dispatcher, Action action, DispatcherPriority priority) 119public static void Invoke(this Dispatcher dispatcher, Action action, TimeSpan timeout) 145public static void Invoke(this Dispatcher dispatcher, Action action, TimeSpan timeout, DispatcherPriority priority)
Templates.Blazor.WebAssembly.Auth.Tests (2)
src\Shared\E2ETesting\WaitAssert.cs (2)
89private static void WaitAssertCore(IWebDriver driver, Action assertion, TimeSpan timeout = default) 143private static ExceptionDispatchInfo CaptureException(Action assertion)
Templates.Blazor.WebAssembly.Tests (2)
src\Shared\E2ETesting\WaitAssert.cs (2)
89private static void WaitAssertCore(IWebDriver driver, Action assertion, TimeSpan timeout = default) 143private static ExceptionDispatchInfo CaptureException(Action assertion)
Templates.Mvc.Tests (2)
src\Shared\E2ETesting\WaitAssert.cs (2)
89private static void WaitAssertCore(IWebDriver driver, Action assertion, TimeSpan timeout = default) 143private static ExceptionDispatchInfo CaptureException(Action assertion)
Templates.Tests (2)
src\Shared\E2ETesting\WaitAssert.cs (2)
89private static void WaitAssertCore(IWebDriver driver, Action assertion, TimeSpan timeout = default) 143private static ExceptionDispatchInfo CaptureException(Action assertion)
Test.Utilities (15)
src\Dependencies\PooledObjects\PooledDelegates.cs (5)
37/// Gets an <see cref="Action"/> delegate, which calls <paramref name="unboundAction"/> with the specified 65public static Releaser GetPooledAction<TArg>(Action<TArg> unboundAction, TArg argument, out Action boundAction) 66=> GetPooledDelegate<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action>(unboundAction, argument, out boundAction); 384: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action> 386protected override Action Bind()
src\Dependencies\Threading\ConfiguredYieldAwaitable.cs (3)
36static continuation => ((Action)continuation!)(); 52public void OnCompleted(Action continuation) 66public void UnsafeOnCompleted(Action continuation)
src\Dependencies\Threading\TaskExtensions.cs (2)
104public void OnCompleted(Action continuation) 114public void UnsafeOnCompleted(Action continuation)
src\Dependencies\Threading\ValueTaskExtensions.cs (4)
135public void OnCompleted(Action continuation) 145public void UnsafeOnCompleted(Action continuation) 235public void OnCompleted(Action continuation) 245public void UnsafeOnCompleted(Action continuation)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Extensions\Compilation\CompilationExtensions.cs (1)
136=> compilation.GetTypeByMetadataName(typeof(Action).FullName!);
Text.Analyzers (15)
src\Dependencies\PooledObjects\PooledDelegates.cs (5)
37/// Gets an <see cref="Action"/> delegate, which calls <paramref name="unboundAction"/> with the specified 65public static Releaser GetPooledAction<TArg>(Action<TArg> unboundAction, TArg argument, out Action boundAction) 66=> GetPooledDelegate<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action>(unboundAction, argument, out boundAction); 384: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<TArg>, TArg, Action<TArg>, Action> 386protected override Action Bind()
src\Dependencies\Threading\ConfiguredYieldAwaitable.cs (3)
36static continuation => ((Action)continuation!)(); 52public void OnCompleted(Action continuation) 66public void UnsafeOnCompleted(Action continuation)
src\Dependencies\Threading\TaskExtensions.cs (2)
104public void OnCompleted(Action continuation) 114public void UnsafeOnCompleted(Action continuation)
src\Dependencies\Threading\ValueTaskExtensions.cs (4)
135public void OnCompleted(Action continuation) 145public void UnsafeOnCompleted(Action continuation) 235public void OnCompleted(Action continuation) 245public void UnsafeOnCompleted(Action continuation)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Extensions\Compilation\CompilationExtensions.cs (1)
136=> compilation.GetTypeByMetadataName(typeof(Action).FullName!);
TlsFeaturesObserve (1)
HttpSys\HttpSysConfigurator.cs (1)
100static void CallHttpApi(Action body)
UnitTests.Common (25)
IMockCommunicationObject.cs (6)
17Action OnAbortOverride { get; set; } 25Action OnOpeningOverride { get; set; } 26Action OnOpenedOverride { get; set; } 27Action OnClosingOverride { get; set; } 28Action OnClosedOverride { get; set; } 29Action OnFaultedOverride { get; set; }
MockChannelBase.cs (6)
57public Action OnAbortOverride { get; set; } 66public Action OnOpeningOverride { get; set; } 67public Action OnOpenedOverride { get; set; } 68public Action OnClosingOverride { get; set; } 69public Action OnClosedOverride { get; set; } 70public Action OnFaultedOverride { get; set; }
MockChannelFactory.cs (6)
56public Action OnAbortOverride { get; set; } 65public Action OnOpeningOverride { get; set; } 66public Action OnOpenedOverride { get; set; } 67public Action OnClosingOverride { get; set; } 68public Action OnClosedOverride { get; set; } 69public Action OnFaultedOverride { get; set; }
MockCommunicationObject.cs (6)
52public Action OnAbortOverride { get; set; } 61public Action OnOpeningOverride { get; set; } 62public Action OnOpenedOverride { get; set; } 63public Action OnClosingOverride { get; set; } 64public Action OnClosedOverride { get; set; } 65public Action OnFaultedOverride { get; set; }
TestTypes.cs (1)
317public static void Run(Action asyncMethod)
VBCSCompiler.UnitTests (1)
TestableClientConnection.cs (1)
21public Action DisposeFunc { get; set; } = delegate { };
Wasm.Performance.ConsoleHost (1)
NullDispatcher.cs (1)
15public override Task InvokeAsync(Action workItem)
Wasm.Performance.Driver (1)
Program.cs (1)
296static void RunInBackgroundThread(Action action)
WindowsBase.Tests (7)
Helpers.cs (1)
16public static void ExecuteOnDifferentThread(Action action, ApartmentState? state = null)
System\Windows\Data\DataSourceProviderTests.cs (3)
1871public Action? BeginQueryAction { get; set; } 1892public Action? BeginInitAction { get; set; } 1904public Action? EndInitAction { get; set; }
System\Windows\FreezableTests.cs (1)
7302public Action? OnChangedAction { get; set; }
System\Windows\Threading\DispatcherPriorityAwaiterTests.cs (1)
102Action action = () =>
System\Windows\Threading\DispatcherTests.cs (1)
144Assert.Throws<InvalidEnumArgumentException>("priority", () => dispatcher.BeginInvoke(priority, (Action)(() => { })));
WinFormsControlsTest (1)
TaskDialogSamples.cs (1)
29void AddButtonForAction(string name, Action action)
XmlFileLogger (1)
XmlFileLogger.cs (1)
76private void TryProcessEvent(Action processEvent)
xunit.assert (34)
EventAsserts.cs (26)
43 Action<Action> attach, 44 Action<Action> detach, 45 Action testCode) 63 Action testCode) 88 Action testCode) 117 Action attach, 118 Action detach, 119 Action testCode) 143 Action testCode) 165 Action testCode) 187 Action testCode) 271 Action<Action> attach, 272 Action<Action> detach, 332 Action<Action> attach, 333 Action<Action> detach, 334 Action testCode) 341 Action handler = () => result = true; 356 Action testCode) 381 Action testCode) 400 Action testCode) 422 Action attach, 423 Action detach, 424 Action testCode) 438 Action<Action> attach, 439 Action<Action> detach, 447 Action handler = () => result = true;
ExceptionAsserts.cs (4)
58 Action testCode) => 93 public static T Throws<T>(Action testCode) 138 Action testCode) 214 public static T ThrowsAny<T>(Action testCode)
MultipleAsserts.cs (2)
28 public static void Multiple(params Action[] checks) 35 foreach (var check in checks)
PropertyAsserts.cs (1)
38 Action testCode)
Record.cs (1)
37 protected static Exception? RecordException(Action testCode)
xunit.console (1)
common\ConsoleHelper.cs (1)
10internal static Action ResetColor;