1771 references to Action
aspire (1)
Commands\RunCommand.cs (1)
401public void ProcessResourceState(RpcResourceState resourceState, Action<string, string> endpointWriter)
Aspire.Azure.Npgsql.EntityFrameworkCore.PostgreSQL (1)
src\Components\Common\EntityFrameworkUtils.cs (1)
17public static TSettings GetDbContextSettings<TContext, TSettings>(this IHostApplicationBuilder builder, string defaultConfigSectionName, string? connectionName, Action<TSettings, IConfiguration> bindSettings)
Aspire.Cli.Tests (2)
TestServices\TestExtensionInteractionService.cs (2)
126public Action<int, string>? RequestAppHostAttachCallback { get; set; } 134public Action<LogLevel, string>? LogMessageCallback { get; set; }
Aspire.Components.Common.TestUtilities (1)
ConformanceTests.cs (1)
568private static bool CheckIfImplemented(Action<TOptions, bool> action)
Aspire.Confluent.Kafka (34)
AspireKafkaConsumerExtensions.cs (17)
25/// <inheritdoc cref="AddKafkaConsumer{TKey,TValue}(IHostApplicationBuilder, string, Action{KafkaConsumerSettings}?, Action{IServiceProvider,ConsumerBuilder{TKey,TValue}}?)"/> 29/// <inheritdoc cref="AddKafkaConsumer{TKey,TValue}(IHostApplicationBuilder, string, Action{KafkaConsumerSettings}?, Action{IServiceProvider,ConsumerBuilder{TKey,TValue}}?)"/> 33/// <inheritdoc cref="AddKafkaConsumer{TKey,TValue}(IHostApplicationBuilder, string, Action{KafkaConsumerSettings}?, Action{IServiceProvider,ConsumerBuilder{TKey,TValue}}?)"/> 37/// <inheritdoc cref="AddKafkaConsumer{TKey,TValue}(IHostApplicationBuilder, string, Action{KafkaConsumerSettings}?, Action{IServiceProvider,ConsumerBuilder{TKey,TValue}}?)"/> 38public static void AddKafkaConsumer<TKey, TValue>(this IHostApplicationBuilder builder, string connectionName, Action<IServiceProvider, ConsumerBuilder<TKey, TValue>>? configureBuilder) 41/// <inheritdoc cref="AddKafkaConsumer{TKey,TValue}(IHostApplicationBuilder, string, Action{KafkaConsumerSettings}?, Action{IServiceProvider,ConsumerBuilder{TKey,TValue}}?)"/> 53public static void AddKafkaConsumer<TKey, TValue>(this IHostApplicationBuilder builder, string connectionName, Action<KafkaConsumerSettings>? configureSettings, Action<IServiceProvider, ConsumerBuilder<TKey, TValue>>? configureBuilder) 56/// <inheritdoc cref="AddKeyedKafkaConsumer{TKey, TValue}(IHostApplicationBuilder, string, Action{KafkaConsumerSettings}?, Action{IServiceProvider, ConsumerBuilder{TKey, TValue}}?)"/> 64/// <inheritdoc cref="AddKeyedKafkaConsumer{TKey, TValue}(IHostApplicationBuilder, string, Action{KafkaConsumerSettings}?, Action{IServiceProvider, ConsumerBuilder{TKey, TValue}}?)"/> 72/// <inheritdoc cref="AddKeyedKafkaConsumer{TKey, TValue}(IHostApplicationBuilder, string, Action{KafkaConsumerSettings}?, Action{IServiceProvider, ConsumerBuilder{TKey, TValue}}?)"/> 80/// <inheritdoc cref="AddKeyedKafkaConsumer{TKey, TValue}(IHostApplicationBuilder, string, Action{KafkaConsumerSettings}?, Action{IServiceProvider, ConsumerBuilder{TKey, TValue}}?)"/> 81public static void AddKeyedKafkaConsumer<TKey, TValue>(this IHostApplicationBuilder builder, string name, Action<IServiceProvider, ConsumerBuilder<TKey, TValue>>? configureBuilder) 88/// <inheritdoc cref="AddKeyedKafkaConsumer{TKey, TValue}(IHostApplicationBuilder, string, Action{KafkaConsumerSettings}?, Action{IServiceProvider, ConsumerBuilder{TKey, TValue}}?)"/> 104public static void AddKeyedKafkaConsumer<TKey, TValue>(this IHostApplicationBuilder builder, string name, Action<KafkaConsumerSettings>? configureSettings, Action<IServiceProvider, ConsumerBuilder<TKey, TValue>>? configureBuilder) 114Action<IServiceProvider, ConsumerBuilder<TKey, TValue>>? configureBuilder, 201private static InstrumentedConsumerBuilder<TKey, TValue> CreateConsumerBuilder<TKey, TValue>(IServiceProvider serviceProvider, Action<IServiceProvider, ConsumerBuilder<TKey, TValue>>? configureBuilder, KafkaConsumerSettings settings) 271private static Action<IServiceProvider, ConsumerBuilder<TKey, TValue>>? Wrap<TKey, TValue>(Action<ConsumerBuilder<TKey, TValue>>? action)
AspireKafkaProducerExtensions.cs (17)
25/// <inheritdoc cref="AddKafkaProducer{TKey, TValue}(IHostApplicationBuilder, string, Action{KafkaProducerSettings}?, Action{IServiceProvider, ProducerBuilder{TKey, TValue}}?)"/> 29/// <inheritdoc cref="AddKafkaProducer{TKey, TValue}(IHostApplicationBuilder, string, Action{KafkaProducerSettings}?, Action{IServiceProvider, ProducerBuilder{TKey, TValue}}?)"/> 33/// <inheritdoc cref="AddKafkaProducer{TKey, TValue}(IHostApplicationBuilder, string, Action{KafkaProducerSettings}?, Action{IServiceProvider, ProducerBuilder{TKey, TValue}}?)"/> 37/// <inheritdoc cref="AddKafkaProducer{TKey, TValue}(IHostApplicationBuilder, string, Action{KafkaProducerSettings}?, Action{IServiceProvider, ProducerBuilder{TKey, TValue}}?)"/> 38public static void AddKafkaProducer<TKey, TValue>(this IHostApplicationBuilder builder, string connectionName, Action<IServiceProvider, ProducerBuilder<TKey, TValue>>? configureBuilder) 41/// <inheritdoc cref="AddKafkaProducer{TKey, TValue}(IHostApplicationBuilder, string, Action{KafkaProducerSettings}?, Action{IServiceProvider, ProducerBuilder{TKey, TValue}}?)"/> 53public static void AddKafkaProducer<TKey, TValue>(this IHostApplicationBuilder builder, string connectionName, Action<KafkaProducerSettings>? configureSettings, Action<IServiceProvider, ProducerBuilder<TKey, TValue>>? configureBuilder) 56/// <inheritdoc cref="AddKeyedKafkaProducer{TKey, TValue}(IHostApplicationBuilder, string, Action{KafkaProducerSettings}?, Action{IServiceProvider, ProducerBuilder{TKey, TValue}}?)"/> 64/// <inheritdoc cref="AddKeyedKafkaProducer{TKey, TValue}(IHostApplicationBuilder, string, Action{KafkaProducerSettings}?, Action{IServiceProvider, ProducerBuilder{TKey, TValue}}?)"/> 72/// <inheritdoc cref="AddKeyedKafkaProducer{TKey, TValue}(IHostApplicationBuilder, string, Action{KafkaProducerSettings}?, Action{IServiceProvider, ProducerBuilder{TKey, TValue}}?)"/> 80/// <inheritdoc cref="AddKeyedKafkaProducer{TKey, TValue}(IHostApplicationBuilder, string, Action{KafkaProducerSettings}?, Action{IServiceProvider, ProducerBuilder{TKey, TValue}}?)"/> 81public static void AddKeyedKafkaProducer<TKey, TValue>(this IHostApplicationBuilder builder, string name, Action<IServiceProvider, ProducerBuilder<TKey, TValue>>? configureBuilder) 88/// <inheritdoc cref="AddKeyedKafkaProducer{TKey, TValue}(IHostApplicationBuilder, string, Action{KafkaProducerSettings}?, Action{IServiceProvider, ProducerBuilder{TKey, TValue}}?)"/> 104public static void AddKeyedKafkaProducer<TKey, TValue>(this IHostApplicationBuilder builder, string name, Action<KafkaProducerSettings>? configureSettings, Action<IServiceProvider, ProducerBuilder<TKey, TValue>>? configureBuilder) 114Action<IServiceProvider, ProducerBuilder<TKey, TValue>>? configureBuilder, 201private static InstrumentedProducerBuilder<TKey, TValue> CreateProducerBuilder<TKey, TValue>(IServiceProvider serviceProvider, Action<IServiceProvider, ProducerBuilder<TKey, TValue>>? configureBuilder, KafkaProducerSettings settings) 272private static Action<IServiceProvider, ProducerBuilder<TKey, TValue>>? Wrap<TKey, TValue>(Action<ProducerBuilder<TKey, TValue>>? action)
Aspire.Confluent.Kafka.Tests (8)
ConfluentKafkaPublicApiTests.cs (8)
25Action<IServiceProvider, ConsumerBuilder<string, string>>? configureBuilderWithServiceProvider = null; 61Action<IServiceProvider, ConsumerBuilder<string, string>>? configureBuilderWithServiceProvider = null; 93Action<IServiceProvider, ConsumerBuilder<string, string>>? configureBuilderWithServiceProvider = null; 129Action<IServiceProvider, ConsumerBuilder<string, string>>? configureBuilderWithServiceProvider = null; 161Action<IServiceProvider, ProducerBuilder<string, string>>? configureBuilderWithServiceProvider = null; 197Action<IServiceProvider, ProducerBuilder<string, string>>? configureBuilderWithServiceProvider = null; 229Action<IServiceProvider, ProducerBuilder<string, string>>? configureBuilderWithServiceProvider = null; 265Action<IServiceProvider, ProducerBuilder<string, string>>? configureBuilderWithServiceProvider = null;
Aspire.Dashboard.Components.Tests (4)
Shared\TestDialogService.cs (2)
21public event Action<string, DialogParameters>? OnUpdate; 23public event Action<IDialogReference, DialogResult>? OnDialogCloseRequested;
Shared\TestLocalStorage.cs (1)
11public Action<string, object?>? OnSetUnprotectedAsync { get; set; }
Shared\TestSessionStorage.cs (1)
11public Action<string, object?>? OnSetAsync { get; set; }
Aspire.Dashboard.Tests (1)
OtlpApiKeyAuthenticationHandlerTests.cs (1)
112public IDisposable OnChange(Action<T, string> listener) => throw new NotImplementedException();
Aspire.Hosting (1)
ApplicationModel\ResourceExtensions.cs (1)
392Action<string?, Exception?> processValue,
Aspire.Hosting.Azure.AppContainers (7)
AzureContainerAppContainerExtensions.cs (1)
34public static IResourceBuilder<T> PublishAsAzureContainerApp<T>(this IResourceBuilder<T> container, Action<AzureResourceInfrastructure, ContainerApp> configure)
AzureContainerAppCustomizationAnnotation.cs (2)
12public sealed class AzureContainerAppCustomizationAnnotation(Action<AzureResourceInfrastructure, ContainerApp> configure) 18public Action<AzureResourceInfrastructure, ContainerApp> Configure { get; } = configure ?? throw new ArgumentNullException(nameof(configure));
AzureContainerAppExecutableExtensions.cs (1)
34public static IResourceBuilder<T> PublishAsAzureContainerApp<T>(this IResourceBuilder<T> executable, Action<AzureResourceInfrastructure, ContainerApp> configure)
AzureContainerAppProjectExtensions.cs (1)
34public static IResourceBuilder<T> PublishAsAzureContainerApp<T>(this IResourceBuilder<T> project, Action<AzureResourceInfrastructure, ContainerApp> configure)
ContainerAppExtensions.cs (2)
29/// in conjunction with the <see cref="AzureContainerAppContainerExtensions.PublishAsAzureContainerApp{T}(IResourceBuilder{T}, Action{AzureResourceInfrastructure, ContainerApp})"/> 43/// method via the <see cref="AzureContainerAppContainerExtensions.PublishAsAzureContainerApp{T}(IResourceBuilder{T}, Action{AzureResourceInfrastructure, ContainerApp})"/>
Aspire.Hosting.Azure.AppService (3)
AzureAppServiceComputeResourceExtensions.cs (1)
32public static IResourceBuilder<T> PublishAsAzureAppServiceWebsite<T>(this IResourceBuilder<T> builder, Action<AzureResourceInfrastructure, WebSite> configure)
AzureAppServiceWebsiteCustomizationAnnotation.cs (2)
12public sealed class AzureAppServiceWebsiteCustomizationAnnotation(Action<AzureResourceInfrastructure, WebSite> configure) 18public Action<AzureResourceInfrastructure, WebSite> Configure { get; } = configure ?? throw new ArgumentNullException(nameof(configure));
Aspire.Hosting.Azure.Tests (7)
PublicApiTests\AppContainersPublicApiTests.cs (7)
17Action<AzureResourceInfrastructure, ContainerApp> configure = (r, c) => { }; 30Action<AzureResourceInfrastructure, ContainerApp> configure = null!; 41Action<AzureResourceInfrastructure, ContainerApp> configure = null!; 53Action<AzureResourceInfrastructure, ContainerApp> configure = (r, c) => { }; 66Action<AzureResourceInfrastructure, ContainerApp> configure = null!; 94Action<AzureResourceInfrastructure, ContainerApp> configure = (r, c) => { }; 107Action<AzureResourceInfrastructure, ContainerApp> configure = null!;
Aspire.Hosting.Docker (3)
DockerComposeServiceCustomizationAnnotation.cs (2)
16public sealed class DockerComposeServiceCustomizationAnnotation(Action<DockerComposeServiceResource, Service> configure) : IResourceAnnotation 22public Action<DockerComposeServiceResource, Service> Configure { get; } = configure ?? throw new ArgumentNullException(nameof(configure));
DockerComposeServiceExtensions.cs (1)
36public static IResourceBuilder<T> PublishAsDockerComposeService<T>(this IResourceBuilder<T> builder, Action<DockerComposeServiceResource, Service> configure)
Aspire.Hosting.Testing (14)
DistributedApplicationEntryPointInvoker.cs (6)
20Action<DistributedApplicationOptions, HostApplicationBuilderSettings>? onConstructing = null, 50private readonly Action<DistributedApplicationOptions, HostApplicationBuilderSettings>? _onConstructing; 58Action<DistributedApplicationOptions, HostApplicationBuilderSettings>? onConstructing, 212private readonly Action<DistributedApplicationOptions, HostApplicationBuilderSettings>? _onConstructing; 215private TestingBuilderFactory(Action<DistributedApplicationOptions, HostApplicationBuilderSettings>? onConstructing) 222Action<DistributedApplicationOptions, HostApplicationBuilderSettings>? onConstructing)
DistributedApplicationFactory.cs (1)
241Action<DistributedApplicationOptions, HostApplicationBuilderSettings> configureBuilder)
DistributedApplicationTestingBuilder.cs (7)
88public static Task<IDistributedApplicationTestingBuilder> CreateAsync<TEntryPoint>(string[] args, Action<DistributedApplicationOptions, HostApplicationBuilderSettings> configureBuilder, CancellationToken cancellationToken = default) 102public static async Task<IDistributedApplicationTestingBuilder> CreateAsync(Type entryPoint, string[] args, Action<DistributedApplicationOptions, HostApplicationBuilderSettings> configureBuilder, CancellationToken cancellationToken = default) 130public static IDistributedApplicationTestingBuilder Create(string[] args, Action<DistributedApplicationOptions, HostApplicationBuilderSettings> configureBuilder) 149Action<DistributedApplicationOptions, HostApplicationBuilderSettings> configureBuilder, 175private sealed class SuspendingDistributedApplicationFactory(Type entryPoint, string[] args, Action<DistributedApplicationOptions, HostApplicationBuilderSettings> configureBuilder) 316Action<DistributedApplicationOptions, HostApplicationBuilderSettings> configureBuilder, 325Action<DistributedApplicationOptions, HostApplicationBuilderSettings> configureBuilder,
Aspire.Hosting.Testing.Tests (14)
TestingBuilderTests.cs (4)
84Action<DistributedApplicationOptions, HostApplicationBuilderSettings> configureBuilder = (options, settings) => 216Action<DistributedApplicationOptions, HostApplicationBuilderSettings> configureBuilder = directArgs switch 301Action<DistributedApplicationOptions, HostApplicationBuilderSettings> configureBuilder; 350Action<DistributedApplicationOptions, HostApplicationBuilderSettings> configureBuilder;
TestingPublicApiTests.cs (10)
291Action<DistributedApplicationOptions, HostApplicationBuilderSettings> configureBuilder = (_, _) => { }; 303Action<DistributedApplicationOptions, HostApplicationBuilderSettings> configureBuilder = null!; 317Action<DistributedApplicationOptions, HostApplicationBuilderSettings> configureBuilder = (_, _) => { }; 336Action<DistributedApplicationOptions, HostApplicationBuilderSettings> configureBuilder = (_, _) => { }; 349Action<DistributedApplicationOptions, HostApplicationBuilderSettings> configureBuilder = (_, _) => { }; 362Action<DistributedApplicationOptions, HostApplicationBuilderSettings> configureBuilder = null!; 377Action<DistributedApplicationOptions, HostApplicationBuilderSettings> configureBuilder = (_, _) => { }; 425Action<DistributedApplicationOptions, HostApplicationBuilderSettings> configureBuilder = (_, _) => { }; 437Action<DistributedApplicationOptions, HostApplicationBuilderSettings> configureBuilder = null!; 451Action<DistributedApplicationOptions, HostApplicationBuilderSettings> configureBuilder = (_, _) => { };
Aspire.Hosting.Yarp.Tests (1)
YarpFunctionalTests.cs (1)
27private async Task VerifyYarpResource(Action<IResourceBuilder<YarpResource>, EndpointReference> configurator)
Aspire.Microsoft.EntityFrameworkCore.Cosmos (1)
src\Components\Common\EntityFrameworkUtils.cs (1)
17public static TSettings GetDbContextSettings<TContext, TSettings>(this IHostApplicationBuilder builder, string defaultConfigSectionName, string? connectionName, Action<TSettings, IConfiguration> bindSettings)
Aspire.Microsoft.EntityFrameworkCore.SqlServer (1)
src\Components\Common\EntityFrameworkUtils.cs (1)
17public static TSettings GetDbContextSettings<TContext, TSettings>(this IHostApplicationBuilder builder, string defaultConfigSectionName, string? connectionName, Action<TSettings, IConfiguration> bindSettings)
Aspire.Npgsql.EntityFrameworkCore.PostgreSQL (1)
src\Components\Common\EntityFrameworkUtils.cs (1)
17public static TSettings GetDbContextSettings<TContext, TSettings>(this IHostApplicationBuilder builder, string defaultConfigSectionName, string? connectionName, Action<TSettings, IConfiguration> bindSettings)
Aspire.Oracle.EntityFrameworkCore (1)
src\Components\Common\EntityFrameworkUtils.cs (1)
17public static TSettings GetDbContextSettings<TContext, TSettings>(this IHostApplicationBuilder builder, string defaultConfigSectionName, string? connectionName, Action<TSettings, IConfiguration> bindSettings)
Aspire.Pomelo.EntityFrameworkCore.MySql (1)
src\Components\Common\EntityFrameworkUtils.cs (1)
17public static TSettings GetDbContextSettings<TContext, TSettings>(this IHostApplicationBuilder builder, string defaultConfigSectionName, string? connectionName, Action<TSettings, IConfiguration> bindSettings)
Aspire.StackExchange.Redis (2)
src\Vendoring\OpenTelemetry.Instrumentation.StackExchangeRedis\StackExchangeRedisInstrumentationOptions.cs (1)
32public Action<Activity, IProfiledCommand>? Enrich { get; set; }
src\Vendoring\OpenTelemetry.Instrumentation.StackExchangeRedis\TracerProviderBuilderExtensions.cs (1)
156Action<IServiceProvider, StackExchangeRedisInstrumentation> configure)
Aspire.StackExchange.Redis.DistributedCaching (1)
AspireRedisDistributedCacheExtensions.cs (1)
77private static void AddRedisDistributedCacheCore(this IHostApplicationBuilder builder, Action<RedisCacheOptions, IServiceProvider> configureRedisOptions)
Aspire.StackExchange.Redis.OutputCaching (1)
AspireRedisOutputCacheExtensions.cs (1)
76private static void AddRedisOutputCacheCore(this IHostApplicationBuilder builder, Action<RedisOutputCacheOptions, IServiceProvider> configureRedisOptions)
dotnet-svcutil-lib (7)
FrameworkFork\System.ServiceModel\Internals\System\Runtime\AsyncResult.cs (2)
95protected Action<AsyncResult, Exception> OnCompleting { get; set; } 106protected Action<AsyncCallback, IAsyncResult> VirtualCallback
FrameworkFork\System.ServiceModel\Internals\System\Runtime\InputQueue.cs (2)
38public InputQueue(Func<Action<AsyncCallback, IAsyncResult>> asyncCallbackGenerator) 64private Func<Action<AsyncCallback, IAsyncResult>> AsyncCallbackGenerator
FrameworkFork\System.ServiceModel\System\ServiceModel\Channels\Connection.cs (2)
448private Action<Task<int>, object> _onRead; 449private Action<Task, object> _onWrite;
FrameworkFork\System.ServiceModel\System\ServiceModel\Diagnostics\TraceAsyncResult.cs (1)
12private static Action<AsyncCallback, IAsyncResult> s_waitResultCallback = new Action<AsyncCallback, IAsyncResult>(DoCallback);
GenerateDocumentationAndConfigFiles (21)
src\Dependencies\PooledObjects\PooledDelegates.cs (8)
98public static Releaser GetPooledAction<T1, TArg>(Action<T1, TArg> unboundAction, TArg argument, out Action<T1> boundAction) 99=> GetPooledDelegate<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>>(unboundAction, argument, out boundAction); 102/// Gets an <see cref="Action{T1, T2}"/> delegate, which calls <paramref name="unboundAction"/> with the specified 132public static Releaser GetPooledAction<T1, T2, TArg>(Action<T1, T2, TArg> unboundAction, TArg argument, out Action<T1, T2> boundAction) 133=> GetPooledDelegate<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>>(unboundAction, argument, out boundAction); 391: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>> 398: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>> 400protected override Action<T1, T2> Bind()
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Extensions\ObjectWriterExtensions.cs (1)
13public static void WriteArray<T>(this ObjectWriter writer, ImmutableArray<T> values, Action<ObjectWriter, T> write)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\FlowAnalysis\SymbolUsageAnalysis\SymbolUsageAnalysis.BasicBlockAnalysisData.cs (1)
74public void ForEachCurrentWrite<TArg>(ISymbol symbol, Action<IOperation, TArg> action, TArg arg)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Formatting\Engine\AbstractFormatEngine.cs (6)
167var addIndentBlockOperations = _formattingRules.AddIndentBlockOperations; 168var addSuppressOperation = _formattingRules.AddSuppressOperations; 169var addAlignTokensOperations = _formattingRules.AddAlignTokensOperations; 170var addAnchorIndentationOperations = _formattingRules.AddAnchorIndentationOperations; 189private static void AddOperations<T>(SegmentedList<T> operations, List<T> scratch, SyntaxNode node, Action<List<T>, SyntaxNode> addOperations) 203private static void AddOperations<T>(SegmentedList<T> operations, ArrayBuilder<T> scratch, SyntaxNode node, Action<ArrayBuilder<T>, SyntaxNode> addOperations)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\NamingStyles\Serialization\NamingStylePreferencesEditorConfigSerializer.cs (1)
51Action<string, string> entryWriter,
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\ObjectPools\PooledObject.cs (2)
19private readonly Action<ObjectPool<T>, T> _releaser; 22public PooledObject(ObjectPool<T> pool, Func<ObjectPool<T>, T> allocator, Action<ObjectPool<T>, T> releaser) : this()
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Extensions\StringBuilderExtensions.cs (2)
21this StringBuilder builder, string separator, SeparatedSyntaxList<TNode> values, Action<TNode, StringBuilder> append) 37public static StringBuilder AppendJoinedValues<T>(this StringBuilder builder, string separator, ImmutableArray<T> values, Action<T, StringBuilder> append)
illink (1)
ILLink.RoslynAnalyzer (1)
src\tools\illink\src\ILLink.Shared\DataFlow\ForwardDataFlowAnalysis.cs (1)
192Action<IControlFlowGraph<TBlock, TRegion>.ControlFlowBranch, TValue> updateState
InMemory.FunctionalTests (3)
src\Servers\Kestrel\shared\test\Http3\Http3InMemory.cs (2)
143internal async Task WaitForConnectionErrorAsync<TException>(bool ignoreNonGoAwayFrames, long? expectedLastStreamId, Http3ErrorCode expectedErrorCode, Action<Type, string[]> matchExpectedErrorMessage = null, params string[] expectedErrorMessage) 176private void AssertConnectionError<TException>(Http3ErrorCode expectedErrorCode, Action<Type, string[]> matchExpectedErrorMessage = null, params string[] expectedErrorMessage) where TException : Exception
TestTransport\MockMultiplexedConnectionListenerFactory.cs (1)
15public Action<EndPoint, IFeatureCollection> OnBindAsync { get; set; }
Interop.FunctionalTests (2)
src\Shared\Buffers.MemoryPool\PinnedBlockMemoryPool.cs (2)
62private Action<object?, PinnedBlockMemoryPool>? _onPoolDisposed; 83public void OnPoolDisposed(Action<object?, PinnedBlockMemoryPool> onPoolDisposed, object? state = null)
Metrics (19)
src\Dependencies\PooledObjects\PooledDelegates.cs (8)
98public static Releaser GetPooledAction<T1, TArg>(Action<T1, TArg> unboundAction, TArg argument, out Action<T1> boundAction) 99=> GetPooledDelegate<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>>(unboundAction, argument, out boundAction); 102/// Gets an <see cref="Action{T1, T2}"/> delegate, which calls <paramref name="unboundAction"/> with the specified 132public static Releaser GetPooledAction<T1, T2, TArg>(Action<T1, T2, TArg> unboundAction, TArg argument, out Action<T1, T2> boundAction) 133=> GetPooledDelegate<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>>(unboundAction, argument, out boundAction); 391: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>> 398: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>> 400protected override Action<T1, T2> Bind()
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Extensions\ObjectWriterExtensions.cs (1)
13public static void WriteArray<T>(this ObjectWriter writer, ImmutableArray<T> values, Action<ObjectWriter, T> write)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\FlowAnalysis\SymbolUsageAnalysis\SymbolUsageAnalysis.BasicBlockAnalysisData.cs (1)
74public void ForEachCurrentWrite<TArg>(ISymbol symbol, Action<IOperation, TArg> action, TArg arg)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Formatting\Engine\AbstractFormatEngine.cs (6)
167var addIndentBlockOperations = _formattingRules.AddIndentBlockOperations; 168var addSuppressOperation = _formattingRules.AddSuppressOperations; 169var addAlignTokensOperations = _formattingRules.AddAlignTokensOperations; 170var addAnchorIndentationOperations = _formattingRules.AddAnchorIndentationOperations; 189private static void AddOperations<T>(SegmentedList<T> operations, List<T> scratch, SyntaxNode node, Action<List<T>, SyntaxNode> addOperations) 203private static void AddOperations<T>(SegmentedList<T> operations, ArrayBuilder<T> scratch, SyntaxNode node, Action<ArrayBuilder<T>, SyntaxNode> addOperations)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\NamingStyles\Serialization\NamingStylePreferencesEditorConfigSerializer.cs (1)
51Action<string, string> entryWriter,
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\ObjectPools\PooledObject.cs (2)
19private readonly Action<ObjectPool<T>, T> _releaser; 22public PooledObject(ObjectPool<T> pool, Func<ObjectPool<T>, T> allocator, Action<ObjectPool<T>, T> releaser) : this()
Metrics.Legacy (19)
src\Dependencies\PooledObjects\PooledDelegates.cs (8)
98public static Releaser GetPooledAction<T1, TArg>(Action<T1, TArg> unboundAction, TArg argument, out Action<T1> boundAction) 99=> GetPooledDelegate<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>>(unboundAction, argument, out boundAction); 102/// Gets an <see cref="Action{T1, T2}"/> delegate, which calls <paramref name="unboundAction"/> with the specified 132public static Releaser GetPooledAction<T1, T2, TArg>(Action<T1, T2, TArg> unboundAction, TArg argument, out Action<T1, T2> boundAction) 133=> GetPooledDelegate<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>>(unboundAction, argument, out boundAction); 391: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>> 398: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>> 400protected override Action<T1, T2> Bind()
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Extensions\ObjectWriterExtensions.cs (1)
13public static void WriteArray<T>(this ObjectWriter writer, ImmutableArray<T> values, Action<ObjectWriter, T> write)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\FlowAnalysis\SymbolUsageAnalysis\SymbolUsageAnalysis.BasicBlockAnalysisData.cs (1)
74public void ForEachCurrentWrite<TArg>(ISymbol symbol, Action<IOperation, TArg> action, TArg arg)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Formatting\Engine\AbstractFormatEngine.cs (6)
167var addIndentBlockOperations = _formattingRules.AddIndentBlockOperations; 168var addSuppressOperation = _formattingRules.AddSuppressOperations; 169var addAlignTokensOperations = _formattingRules.AddAlignTokensOperations; 170var addAnchorIndentationOperations = _formattingRules.AddAnchorIndentationOperations; 189private static void AddOperations<T>(SegmentedList<T> operations, List<T> scratch, SyntaxNode node, Action<List<T>, SyntaxNode> addOperations) 203private static void AddOperations<T>(SegmentedList<T> operations, ArrayBuilder<T> scratch, SyntaxNode node, Action<ArrayBuilder<T>, SyntaxNode> addOperations)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\NamingStyles\Serialization\NamingStylePreferencesEditorConfigSerializer.cs (1)
51Action<string, string> entryWriter,
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\ObjectPools\PooledObject.cs (2)
19private readonly Action<ObjectPool<T>, T> _releaser; 22public PooledObject(ObjectPool<T> pool, Func<ObjectPool<T>, T> allocator, Action<ObjectPool<T>, T> releaser) : this()
Microsoft.Analyzers.Extra (21)
CallAnalysis\CallAnalyzer.Handlers.cs (5)
32foreach (var handler in handlers) 50foreach (var action in h.Actions) 69foreach (var action in h.Actions) 91foreach (var handler in handlers) 105foreach (var handler in handlers)
CallAnalysis\CallAnalyzer.Registrar.cs (11)
33public void RegisterMethod(IMethodSymbol method, Action<OperationAnalysisContext, IInvocationOperation> action) 50public void RegisterMethods(string typeName, string methodName, Action<OperationAnalysisContext, IInvocationOperation> action) 66public void RegisterMethods(Dictionary<string, string[]> methods, Action<OperationAnalysisContext, IInvocationOperation> action) 87public void RegisterConstructor(IMethodSymbol ctor, Action<OperationAnalysisContext, IObjectCreationOperation> action) 101public void RegisterConstructors(string typeName, Action<OperationAnalysisContext, IObjectCreationOperation> action) 109public void RegisterConstructors(string[] typeNames, Action<OperationAnalysisContext, IObjectCreationOperation> action) 127public void RegisterProperty(IPropertySymbol prop, Action<OperationAnalysisContext, IPropertyReferenceOperation> action) 144public void RegisterProperties(Dictionary<string, string[]> props, Action<OperationAnalysisContext, IPropertyReferenceOperation> action) 165public void RegisterInterfaceMethod(IMethodSymbol method, Action<OperationAnalysisContext, IInvocationOperation> action) 200public void RegisterInterfaceMethods(Dictionary<string, string[]> methods, Action<OperationAnalysisContext, IInvocationOperation> action) 221public void RegisterExceptionTypes(string[] exceptionTypes, Action<OperationAnalysisContext, IThrowOperation> action)
CallAnalysis\CallAnalyzer.State.cs (5)
16public readonly Dictionary<IMethodSymbol, List<Action<OperationAnalysisContext, IInvocationOperation>>> Methods = new(SymbolEqualityComparer.Default); 17public readonly Dictionary<IMethodSymbol, List<Action<OperationAnalysisContext, IObjectCreationOperation>>> Ctors = new(SymbolEqualityComparer.Default); 18public readonly Dictionary<IPropertySymbol, List<Action<OperationAnalysisContext, IPropertyReferenceOperation>>> Props = new(SymbolEqualityComparer.Default); 19public readonly Dictionary<ITypeSymbol, List<Action<OperationAnalysisContext, IThrowOperation>>> ExceptionTypes = new(SymbolEqualityComparer.Default); 32public List<Action<OperationAnalysisContext, IInvocationOperation>> Actions { get; } = [];
Microsoft.Analyzers.Local (22)
CallAnalysis\CallAnalyzer.Handlers.cs (6)
32foreach (var handler in handlers) 50foreach (var action in h.Actions) 69foreach (var action in h.Actions) 91foreach (var handler in handlers) 105foreach (var handler in handlers) 124foreach (var handler in handlers)
CallAnalysis\CallAnalyzer.Registrar.cs (11)
33public void RegisterMethod(IMethodSymbol method, Action<OperationAnalysisContext, IInvocationOperation> action) 50public void RegisterMethods(string typeName, string methodName, Action<OperationAnalysisContext, IInvocationOperation> action) 66public void RegisterMethods(Dictionary<string, string[]> methods, Action<OperationAnalysisContext, IInvocationOperation> action) 87public void RegisterConstructor(IMethodSymbol ctor, Action<OperationAnalysisContext, IObjectCreationOperation> action) 101public void RegisterConstructors(string typeName, Action<OperationAnalysisContext, IObjectCreationOperation> action) 109public void RegisterConstructors(string[] typeNames, Action<OperationAnalysisContext, IObjectCreationOperation> action) 127public void RegisterProperty(IPropertySymbol prop, Action<OperationAnalysisContext, IPropertyReferenceOperation> action) 144public void RegisterProperties(Dictionary<string, string[]> props, Action<OperationAnalysisContext, IPropertyReferenceOperation> action) 165public void RegisterInterfaceMethod(IMethodSymbol method, Action<OperationAnalysisContext, IInvocationOperation> action) 200public void RegisterInterfaceMethods(Dictionary<string, string[]> methods, Action<OperationAnalysisContext, IInvocationOperation> action) 221public void RegisterExceptionTypes(string[] exceptionTypes, Action<OperationAnalysisContext, IThrowOperation> action)
CallAnalysis\CallAnalyzer.State.cs (5)
16public readonly Dictionary<IMethodSymbol, List<Action<OperationAnalysisContext, IInvocationOperation>>> Methods = new(SymbolEqualityComparer.Default); 17public readonly Dictionary<IMethodSymbol, List<Action<OperationAnalysisContext, IObjectCreationOperation>>> Ctors = new(SymbolEqualityComparer.Default); 18public readonly Dictionary<IPropertySymbol, List<Action<OperationAnalysisContext, IPropertyReferenceOperation>>> Props = new(SymbolEqualityComparer.Default); 19public readonly Dictionary<ITypeSymbol, List<Action<OperationAnalysisContext, IThrowOperation>>> ExceptionTypes = new(SymbolEqualityComparer.Default); 32public List<Action<OperationAnalysisContext, IInvocationOperation>> Actions { get; } = [];
Microsoft.AspNetCore (16)
BootstrapHostBuilder.cs (7)
17private readonly List<Action<HostBuilderContext, IConfigurationBuilder>> _configureAppActions = new(); 18private readonly List<Action<HostBuilderContext, IServiceCollection>> _configureServicesActions = new(); 49public IHostBuilder ConfigureAppConfiguration(Action<HostBuilderContext, IConfigurationBuilder> configureDelegate) 55public IHostBuilder ConfigureServices(Action<HostBuilderContext, IServiceCollection> configureDelegate) 67public IHostBuilder ConfigureContainer<TContainerBuilder>(Action<HostBuilderContext, TContainerBuilder> configureDelegate) 94foreach (var configureAppAction in _configureAppActions) 99foreach (var configureServicesAction in _configureServicesActions)
ConfigureHostBuilder.cs (6)
22private readonly List<Action<HostBuilderContext, object>> _configureContainerActions = new(); 44public IHostBuilder ConfigureAppConfiguration(Action<HostBuilderContext, IConfigurationBuilder> configureDelegate) 52public IHostBuilder ConfigureContainer<TContainerBuilder>(Action<HostBuilderContext, TContainerBuilder> configureDelegate) 95public IHostBuilder ConfigureServices(Action<HostBuilderContext, IServiceCollection> configureDelegate) 128foreach (var action in _configureContainerActions) 138foreach (var action in _configureContainerActions)
ConfigureWebHostBuilder.cs (3)
39public IWebHostBuilder ConfigureAppConfiguration(Action<WebHostBuilderContext, IConfigurationBuilder> configureDelegate) 90public IWebHostBuilder ConfigureServices(Action<WebHostBuilderContext, IServiceCollection> configureServices) 173IWebHostBuilder ISupportsStartup.Configure(Action<WebHostBuilderContext, IApplicationBuilder> configure)
Microsoft.AspNetCore.Components (9)
ComponentFactory.cs (4)
109private static Action<IServiceProvider, IComponent> CreatePropertyInjector([DynamicallyAccessedMembers(Component)] Type type) 173public Action<IServiceProvider, IComponent> PerformPropertyInjection { get; } 177Action<IServiceProvider, IComponent> performPropertyInjection) 185out Action<IServiceProvider, IComponent> performPropertyInjection)
Reflection\PropertySetter.cs (5)
15private readonly Action<object, object> _setterDelegate; 35setMethod.CreateDelegate(typeof(Action<,>).MakeGenericType(targetType, property.PropertyType)); 38_setterDelegate = (Action<object, object>) 39callPropertySetterClosedGenericMethod.CreateDelegate(typeof(Action<object, object>), propertySetterAsAction); 54Action<TTarget, TValue> setter,
Microsoft.AspNetCore.Components.Endpoints (9)
FormMapping\Factories\ComplexType\ComplexTypeExpressionConverterFactoryOfT.cs (1)
218Expression.Constant(null, typeof(Action<string, object>)));
FormMapping\FormDataReader.cs (1)
53public Action<string, object>? AttachInstanceToErrorsHandler { get; set; }
src\Shared\PropertyHelper\PropertyHelper.cs (7)
45private Action<object, object?>? _valueSetter; 83public Action<object, object?> ValueSetter 272public static Action<object, object?> MakeFastPropertySetter(PropertyInfo propertyInfo) 295setMethod.CreateDelegate(typeof(Action<,>).MakeGenericType(typeInput, parameterType)); 300typeof(Action<object, object?>), propertySetterAsAction); 302return (Action<object, object?>)callPropertySetterDelegate; 387Action<TDeclaringType, TValue> setter,
Microsoft.AspNetCore.Components.Tests (2)
ComponentBaseTest.cs (1)
608public Action<TestComponent, bool> OnAfterRenderLogic { get; set; }
RendererTest.cs (1)
652OnArbitraryDelegateEvent = (Action<EventArgs, string>)((x, y) => { }),
Microsoft.AspNetCore.Components.Web (1)
Forms\Mapping\FormValueMappingContext.cs (1)
57public Action<string, object>? MapErrorToContainer { get; set; }
Microsoft.AspNetCore.Components.Web.Tests (1)
Image\ImageTest.cs (1)
227var setProp = (string name, object? value) =>
Microsoft.AspNetCore.Components.WebAssembly (2)
Hosting\WebassemblyHostBuilderExtensions.cs (1)
34Action<IWebAssemblyHostEnvironment, ServiceProviderOptions> configure)
Services\DefaultWebAssemblyJSRuntime.cs (1)
27public event Action<RootComponentOperationBatch, string>? OnUpdateRootComponents;
Microsoft.AspNetCore.Components.WebView.Photino (1)
PhotinoSynchronizationContext.cs (1)
30private static readonly Action<Task, object> BackgroundWorkThunk = (Task task, object state) =>
Microsoft.AspNetCore.CookiePolicy (1)
CookiePolicyServiceCollectionExtensions.cs (1)
33public static IServiceCollection AddCookiePolicy<TService>(this IServiceCollection services, Action<CookiePolicyOptions, TService> configureOptions) where TService : class
Microsoft.AspNetCore.Diagnostics (1)
ExceptionHandler\ExceptionHandlerServiceCollectionExtensions.cs (1)
35public static IServiceCollection AddExceptionHandler<TService>(this IServiceCollection services, Action<ExceptionHandlerOptions, TService> configureOptions) where TService : class
Microsoft.AspNetCore.Grpc.JsonTranscoding (1)
Internal\Json\MessageTypeInfoResolver.cs (1)
146private static Action<object, object?> GetSetMethod(FieldDescriptor field, FieldDescriptor? wrapperTypeValueField)
Microsoft.AspNetCore.Grpc.Swagger (1)
Internal\GrpcModelMetadata.cs (1)
47public override Action<object, object> PropertySetter { get; }
Microsoft.AspNetCore.HostFiltering.Tests (2)
MiddlewareConfigurationManagerTests.cs (2)
98private event Action<T, string> _listener; 105public IDisposable OnChange(Action<T, string> listener)
Microsoft.AspNetCore.Hosting (21)
GenericHost\GenericWebHostBuilder.cs (2)
295var actionType = typeof(Action<,>).MakeGenericType(typeof(HostBuilderContext), containerType); 341public IWebHostBuilder Configure(Action<WebHostBuilderContext, IApplicationBuilder> configure)
GenericHost\HostingStartupWebHostBuilder.cs (6)
18private Action<WebHostBuilderContext, IConfigurationBuilder>? _configureConfiguration; 19private Action<WebHostBuilderContext, IServiceCollection>? _configureServices; 33public IWebHostBuilder ConfigureAppConfiguration(Action<WebHostBuilderContext, IConfigurationBuilder> configureDelegate) 44public IWebHostBuilder ConfigureServices(Action<WebHostBuilderContext, IServiceCollection> configureServices) 68public IWebHostBuilder UseDefaultServiceProvider(Action<WebHostBuilderContext, ServiceProviderOptions> configure) 78public IWebHostBuilder Configure(Action<WebHostBuilderContext, IApplicationBuilder> configure)
GenericHost\ISupportsUseDefaultServiceProvider.cs (1)
10IWebHostBuilder UseDefaultServiceProvider(Action<WebHostBuilderContext, ServiceProviderOptions> configure);
GenericHost\SlimWebHostBuilder.cs (1)
77public IWebHostBuilder Configure(Action<WebHostBuilderContext, IApplicationBuilder> configure)
GenericHost\WebHostBuilderBase.cs (3)
36public IWebHostBuilder ConfigureAppConfiguration(Action<WebHostBuilderContext, IConfigurationBuilder> configureDelegate) 52public IWebHostBuilder ConfigureServices(Action<WebHostBuilderContext, IServiceCollection> configureServices) 63public IWebHostBuilder UseDefaultServiceProvider(Action<WebHostBuilderContext, ServiceProviderOptions> configure)
Infrastructure\ISupportsStartup.cs (1)
29IWebHostBuilder Configure(Action<WebHostBuilderContext, IApplicationBuilder> configure);
WebHostBuilder.cs (4)
32private Action<WebHostBuilderContext, IServiceCollection>? _configureServices; 33private Action<WebHostBuilderContext, IConfigurationBuilder>? _configureAppConfigurationBuilder; 106public IWebHostBuilder ConfigureServices(Action<WebHostBuilderContext, IServiceCollection> configureServices) 121public IWebHostBuilder ConfigureAppConfiguration(Action<WebHostBuilderContext, IConfigurationBuilder> configureDelegate)
WebHostBuilderExtensions.cs (3)
60public static IWebHostBuilder Configure(this IWebHostBuilder hostBuilder, Action<WebHostBuilderContext, IApplicationBuilder> configureApp) 193public static IWebHostBuilder UseDefaultServiceProvider(this IWebHostBuilder hostBuilder, Action<WebHostBuilderContext, ServiceProviderOptions> configure) 241public static IWebHostBuilder ConfigureLogging(this IWebHostBuilder hostBuilder, Action<WebHostBuilderContext, ILoggingBuilder> configureLogging)
Microsoft.AspNetCore.Hosting.Abstractions (2)
IWebHostBuilder.cs (2)
30IWebHostBuilder ConfigureAppConfiguration(Action<WebHostBuilderContext, IConfigurationBuilder> configureDelegate); 46IWebHostBuilder ConfigureServices(Action<WebHostBuilderContext, IServiceCollection> configureServices);
Microsoft.AspNetCore.Hosting.Tests (4)
Fakes\GenericWebHostBuilderWrapper.cs (4)
38public IWebHostBuilder Configure(Action<WebHostBuilderContext, IApplicationBuilder> configure) 44public IWebHostBuilder ConfigureAppConfiguration(Action<WebHostBuilderContext, IConfigurationBuilder> configureDelegate) 56public IWebHostBuilder ConfigureServices(Action<WebHostBuilderContext, IServiceCollection> configureServices) 67public IWebHostBuilder UseDefaultServiceProvider(Action<WebHostBuilderContext, ServiceProviderOptions> configure)
Microsoft.AspNetCore.Http.Abstractions (7)
src\Shared\PropertyHelper\PropertyHelper.cs (7)
45private Action<object, object?>? _valueSetter; 83public Action<object, object?> ValueSetter 272public static Action<object, object?> MakeFastPropertySetter(PropertyInfo propertyInfo) 295setMethod.CreateDelegate(typeof(Action<,>).MakeGenericType(typeInput, parameterType)); 300typeof(Action<object, object?>), propertySetterAsAction); 302return (Action<object, object?>)callPropertySetterDelegate; 387Action<TDeclaringType, TValue> setter,
Microsoft.AspNetCore.Http.Extensions (18)
src\Components\Endpoints\src\FormMapping\Factories\ComplexType\ComplexTypeExpressionConverterFactoryOfT.cs (1)
218Expression.Constant(null, typeof(Action<string, object>)));
src\Components\Endpoints\src\FormMapping\FormDataReader.cs (1)
53public Action<string, object>? AttachInstanceToErrorsHandler { get; set; }
src\Shared\ObjectMethodExecutor\ObjectMethodExecutor.cs (7)
26typeof(Action<object, Action>), // onCompletedMethod 27typeof(Action<object, Action>) // unsafeOnCompletedMethod 335var onCompletedFunc = Expression.Lambda<Action<object, Action>>( 343Action<object, Action>? unsafeOnCompletedFunc = null; 351unsafeOnCompletedFunc = Expression.Lambda<Action<object, Action>>( 380Expression.Constant(unsafeOnCompletedFunc, typeof(Action<object, Action>)));
src\Shared\ObjectMethodExecutor\ObjectMethodExecutorAwaitable.cs (9)
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) 111var underlyingMethodToUse = _unsafeOnCompletedMethod ?? _onCompletedMethod;
Microsoft.AspNetCore.Http.Extensions.Tests (88)
RequestDelegateFactoryTests.cs (88)
310new object[] { (Action<HttpContext, string[]>)Store, new[] { "plain string" }, new[] { "plain string" } }, 311new object[] { (Action<HttpContext, StringValues>)Store, new[] { "1", "2", "3" }, new StringValues(new[] { "1", "2", "3" }) }, 312new object[] { (Action<HttpContext, int[]>)Store, new[] { "-1", "2", "3" }, new[] { -1,2,3 } }, 313new object[] { (Action<HttpContext, uint[]>)Store, new[] { "1","42","32"}, new[] { 1U, 42U, 32U } }, 314new object[] { (Action<HttpContext, bool[]>)Store, new[] { "true", "false" }, new[] { true, false } }, 315new object[] { (Action<HttpContext, short[]>)Store, new[] { "-42" }, new[] { (short)-42 } }, 316new object[] { (Action<HttpContext, ushort[]>)Store, new[] { "42" }, new[] { (ushort)42 } }, 317new object[] { (Action<HttpContext, long[]>)Store, new[] { "-42" }, new[] { -42L } }, 318new object[] { (Action<HttpContext, ulong[]>)Store, new[] { "42" }, new[] { 42UL } }, 319new object[] { (Action<HttpContext, IntPtr[]>)Store, new[] { "-42" },new[] { new IntPtr(-42) } }, 320new object[] { (Action<HttpContext, char[]>)Store, new[] { "A" }, new[] { 'A' } }, 321new object[] { (Action<HttpContext, double[]>)Store, new[] { "0.5" },new[] { 0.5 } }, 322new object[] { (Action<HttpContext, float[]>)Store, new[] { "0.5" },new[] { 0.5f } }, 323new object[] { (Action<HttpContext, Half[]>)Store, new[] { "0.5" }, new[] { (Half)0.5f } }, 324new object[] { (Action<HttpContext, decimal[]>)Store, new[] { "0.5" },new[] { 0.5m } }, 325new object[] { (Action<HttpContext, Uri[]>)Store, new[] { "https://example.org" }, new[] { new Uri("https://example.org") } }, 326new object[] { (Action<HttpContext, DateTime[]>)Store, new[] { now.ToString("o") },new[] { now.ToUniversalTime() } }, 327new object[] { (Action<HttpContext, DateTimeOffset[]>)Store, new[] { "1970-01-01T00:00:00.0000000+00:00" },new[] { DateTimeOffset.UnixEpoch } }, 328new object[] { (Action<HttpContext, TimeSpan[]>)Store, new[] { "00:00:42" },new[] { TimeSpan.FromSeconds(42) } }, 329new object[] { (Action<HttpContext, Guid[]>)Store, new[] { "00000000-0000-0000-0000-000000000000" },new[] { Guid.Empty } }, 330new object[] { (Action<HttpContext, Version[]>)Store, new[] { "6.0.0.42" }, new[] { new Version("6.0.0.42") } }, 331new object[] { (Action<HttpContext, BigInteger[]>)Store, new[] { "-42" },new[]{ new BigInteger(-42) } }, 332new object[] { (Action<HttpContext, IPAddress[]>)Store, new[] { "127.0.0.1" }, new[] { IPAddress.Loopback } }, 333new object[] { (Action<HttpContext, IPEndPoint[]>)Store, new[] { "127.0.0.1:80" },new[] { new IPEndPoint(IPAddress.Loopback, 80) } }, 334new object[] { (Action<HttpContext, AddressFamily[]>)Store, new[] { "Unix" },new[] { AddressFamily.Unix } }, 335new object[] { (Action<HttpContext, ILOpCode[]>)Store, new[] { "Nop" }, new[] { ILOpCode.Nop } }, 336new object[] { (Action<HttpContext, AssemblyFlags[]>)Store, new[] { "PublicKey,Retargetable" },new[] { AssemblyFlags.PublicKey | AssemblyFlags.Retargetable } }, 337new object[] { (Action<HttpContext, int?[]>)Store, new[] { "42" }, new int?[] { 42 } }, 338new object[] { (Action<HttpContext, MyEnum[]>)Store, new[] { "ValueB" },new[] { MyEnum.ValueB } }, 339new object[] { (Action<HttpContext, MyTryParseRecord[]>)Store, new[] { "https://example.org" },new[] { new MyTryParseRecord(new Uri("https://example.org")) } }, 340new object?[] { (Action<HttpContext, int[]>)Store, new string[] {}, Array.Empty<int>() }, 341new object?[] { (Action<HttpContext, int?[]>)Store, new string?[] { "1", "2", null, "4" }, new int?[] { 1,2, null, 4 } }, 342new object?[] { (Action<HttpContext, int?[]>)Store, new string[] { "1", "2", "", "4" }, new int?[] { 1,2, null, 4 } }, 343new object[] { (Action<HttpContext, MyTryParseRecord?[]?>)Store, new[] { "" }, new MyTryParseRecord?[] { null } }, 362new object[] { (Action<HttpContext, string>)Store, "plain string", "plain string" }, 363new object[] { (Action<HttpContext, int>)Store, "-42", -42 }, 364new object[] { (Action<HttpContext, uint>)Store, "42", 42U }, 365new object[] { (Action<HttpContext, bool>)Store, "true", true }, 366new object[] { (Action<HttpContext, short>)Store, "-42", (short)-42 }, 367new object[] { (Action<HttpContext, ushort>)Store, "42", (ushort)42 }, 368new object[] { (Action<HttpContext, long>)Store, "-42", -42L }, 369new object[] { (Action<HttpContext, ulong>)Store, "42", 42UL }, 370new object[] { (Action<HttpContext, IntPtr>)Store, "-42", new IntPtr(-42) }, 371new object[] { (Action<HttpContext, char>)Store, "A", 'A' }, 372new object[] { (Action<HttpContext, double>)Store, "0.5", 0.5 }, 373new object[] { (Action<HttpContext, float>)Store, "0.5", 0.5f }, 374new object[] { (Action<HttpContext, Half>)Store, "0.5", (Half)0.5f }, 375new object[] { (Action<HttpContext, decimal>)Store, "0.5", 0.5m }, 376new object[] { (Action<HttpContext, Uri>)Store, "https://example.org", new Uri("https://example.org") }, 377new object[] { (Action<HttpContext, DateTime>)Store, now.ToString("o"), now.ToUniversalTime() }, 378new object[] { (Action<HttpContext, DateTimeOffset>)Store, "1970-01-01T00:00:00.0000000+00:00", DateTimeOffset.UnixEpoch }, 379new object[] { (Action<HttpContext, TimeSpan>)Store, "00:00:42", TimeSpan.FromSeconds(42) }, 380new object[] { (Action<HttpContext, Guid>)Store, "00000000-0000-0000-0000-000000000000", Guid.Empty }, 381new object[] { (Action<HttpContext, Version>)Store, "6.0.0.42", new Version("6.0.0.42") }, 382new object[] { (Action<HttpContext, BigInteger>)Store, "-42", new BigInteger(-42) }, 383new object[] { (Action<HttpContext, IPAddress>)Store, "127.0.0.1", IPAddress.Loopback }, 384new object[] { (Action<HttpContext, IPEndPoint>)Store, "127.0.0.1:80", new IPEndPoint(IPAddress.Loopback, 80) }, 385new object[] { (Action<HttpContext, AddressFamily>)Store, "Unix", AddressFamily.Unix }, 386new object[] { (Action<HttpContext, ILOpCode>)Store, "Nop", ILOpCode.Nop }, 387new object[] { (Action<HttpContext, AssemblyFlags>)Store, "PublicKey,Retargetable", AssemblyFlags.PublicKey | AssemblyFlags.Retargetable }, 388new object[] { (Action<HttpContext, int?>)Store, "42", 42 }, 389new object[] { (Action<HttpContext, MyEnum>)Store, "ValueB", MyEnum.ValueB }, 390new object[] { (Action<HttpContext, MyTryParseRecord>)Store, "https://example.org", new MyTryParseRecord(new Uri("https://example.org")) }, 391new object?[] { (Action<HttpContext, int?>)Store, null, null }, 835new[] { (Action<HttpContext, Todo>)TestImpliedFromBody }, 836new[] { (Action<HttpContext, ITodo>)TestImpliedFromBodyInterface }, 837new object[] { (Action<HttpContext, TodoStruct>)TestImpliedFromBodyStruct }, 1093new[] { (Action<HttpContext, MyService>)TestExplicitFromService }, 1095new[] { (Action<HttpContext, IEnumerable<MyService>>)TestExplicitFromIEnumerableService }, 1127new[] { (Action<HttpContext, IMyService>)TestImpliedFromService }, 1129new[] { (Action<HttpContext, IEnumerable<MyService>>)TestImpliedIEnumerableFromService }, 1130new[] { (Action<HttpContext, MyService>)TestImpliedFromServiceBasedOnContainer }, 1664new object?[] { (Action<HttpContext, MyBindAsyncRecord>)requiredReferenceType, false, true, false }, 1665new object?[] { (Action<HttpContext, MyBindAsyncRecord>)requiredReferenceType, true, false, false, }, 1666new object?[] { (Action<HttpContext, MySimpleBindAsyncRecord>)requiredReferenceTypeSimple, true, false, false }, 1668new object?[] { (Action<HttpContext, MyBindAsyncRecord?>)defaultReferenceType, false, false, false, }, 1669new object?[] { (Action<HttpContext, MyBindAsyncRecord?>)defaultReferenceType, true, false, false }, 1671new object?[] { (Action<HttpContext, MyBindAsyncRecord?>)nullableReferenceType, false, false, false }, 1672new object?[] { (Action<HttpContext, MyBindAsyncRecord?>)nullableReferenceType, true, false, false }, 1674new object?[] { (Action<HttpContext, MyNullableBindAsyncStruct>)requiredValueType, false, true, true }, 1675new object?[] { (Action<HttpContext, MyNullableBindAsyncStruct>)requiredValueType, true, false, true }, 1676new object?[] { (Action<HttpContext, MySimpleBindAsyncStruct>)requiredValueTypeSimple, true, false, true }, 1678new object?[] { (Action<HttpContext, MyNullableBindAsyncStruct?>)defaultValueType, false, false, true }, 1679new object?[] { (Action<HttpContext, MyNullableBindAsyncStruct?>)defaultValueType, true, false, true }, 1681new object?[] { (Action<HttpContext, MyNullableBindAsyncStruct?>)nullableValueType, false, false, true }, 1682new object?[] { (Action<HttpContext, MyNullableBindAsyncStruct?>)nullableValueType, true, false, true }, 2621var @delegate = (AddsCustomParameterMetadataBindable param1, AddsCustomParameterMetadata param2) => { }; 3121var @delegate = (string name, HttpContext context) => context.Items.Add("param", name);
Microsoft.AspNetCore.Http.Microbenchmarks (1)
RequestTimeoutsMiddlewareBenchmark.cs (1)
144public IDisposable OnChange(Action<RequestTimeoutOptions, string> listener)
Microsoft.AspNetCore.Http.Tests (1)
Timeouts\RequestTimeoutsMiddlewareTests.cs (1)
391public IDisposable OnChange(Action<RequestTimeoutOptions, string> listener)
Microsoft.AspNetCore.HttpLogging.Tests (2)
OptionsWrapperMonitor.cs (2)
10private event Action<T, string> _listener; 17public IDisposable OnChange(Action<T, string> listener)
Microsoft.AspNetCore.Localization (1)
RequestLocalizationServiceCollectionExtensions.cs (1)
33public static IServiceCollection AddRequestLocalization<TService>(this IServiceCollection services, Action<RequestLocalizationOptions, TService> configureOptions) where TService : class
Microsoft.AspNetCore.Mvc.Abstractions (1)
ModelBinding\ModelMetadata.cs (1)
606public abstract Action<object, object?>? PropertySetter { get; }
Microsoft.AspNetCore.Mvc.Abstractions.Test (1)
ModelBinding\ModelMetadataTest.cs (1)
756public override Action<object, object> PropertySetter
Microsoft.AspNetCore.Mvc.ApiExplorer (1)
EndpointModelMetadata.cs (1)
47public override Action<object, object?>? PropertySetter { get; }
Microsoft.AspNetCore.Mvc.Core (40)
Controllers\ControllerActivatorProvider.cs (3)
15private static readonly Action<ControllerContext, object> _dispose = Dispose; 19private readonly Action<ControllerContext, object>? _controllerActivatorRelease; 63public Action<ControllerContext, object>? CreateReleaser(ControllerActionDescriptor descriptor)
Controllers\ControllerFactoryProvider.cs (5)
13private readonly Action<ControllerContext, object>? _factoryReleaseController; 63var propertyActivator = propertyActivators[i]; 73public Action<ControllerContext, object>? CreateControllerReleaser(ControllerActionDescriptor descriptor) 115private Action<ControllerContext, object>[] GetPropertiesToActivate(ControllerActionDescriptor actionDescriptor) 117var propertyActivators = new Action<ControllerContext, object>[_propertyActivators.Length];
Controllers\DefaultControllerPropertyActivator.cs (1)
33public Action<ControllerContext, object> GetActivatorDelegate(ControllerActionDescriptor actionDescriptor)
Controllers\IControllerActivatorProvider.cs (2)
23Action<ControllerContext, object>? CreateReleaser(ControllerActionDescriptor descriptor); 32var releaser = CreateReleaser(descriptor);
Controllers\IControllerFactoryProvider.cs (2)
23Action<ControllerContext, object>? CreateControllerReleaser(ControllerActionDescriptor descriptor); 32var releaser = CreateControllerReleaser(descriptor);
Controllers\IControllerPropertyActivatorFactory.cs (1)
10Action<ControllerContext, object> GetActivatorDelegate(ControllerActionDescriptor actionDescriptor);
ModelBinding\Metadata\DefaultMetadataDetails.cs (1)
67public Action<object, object?>? PropertySetter { get; set; }
ModelBinding\Metadata\DefaultModelMetadata.cs (1)
551public override Action<object, object?>? PropertySetter => _details.PropertySetter;
src\Shared\ObjectMethodExecutor\ObjectMethodExecutor.cs (7)
26typeof(Action<object, Action>), // onCompletedMethod 27typeof(Action<object, Action>) // unsafeOnCompletedMethod 335var onCompletedFunc = Expression.Lambda<Action<object, Action>>( 343Action<object, Action>? unsafeOnCompletedFunc = null; 351unsafeOnCompletedFunc = Expression.Lambda<Action<object, Action>>( 380Expression.Constant(unsafeOnCompletedFunc, typeof(Action<object, Action>)));
src\Shared\ObjectMethodExecutor\ObjectMethodExecutorAwaitable.cs (9)
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) 111var underlyingMethodToUse = _unsafeOnCompletedMethod ?? _onCompletedMethod;
src\Shared\PropertyActivator\PropertyActivator.cs (1)
15private readonly Action<object, object> _fastPropertySetter;
src\Shared\PropertyHelper\PropertyHelper.cs (7)
45private Action<object, object?>? _valueSetter; 83public Action<object, object?> ValueSetter 272public static Action<object, object?> MakeFastPropertySetter(PropertyInfo propertyInfo) 295setMethod.CreateDelegate(typeof(Action<,>).MakeGenericType(typeInput, parameterType)); 300typeof(Action<object, object?>), propertySetterAsAction); 302return (Action<object, object?>)callPropertySetterDelegate; 387Action<TDeclaringType, TValue> setter,
Microsoft.AspNetCore.Mvc.Core.Test (10)
ApplicationParts\ApplicationPartManagerTest.cs (4)
112private readonly Action<ViewComponentsFeature, string> _operation; 114public NotControllersedFeatureProvider(Action<ViewComponentsFeature, string> operation) 130private readonly Action<ControllersFeature, string> _operation; 132public ControllersFeatureProvider(Action<ControllersFeature, string> operation)
Controllers\ControllerActivatorProviderTest.cs (3)
84var releaseDelegate = activatorProvider.CreateReleaser(descriptor); 103var releaseDelegate = activatorProvider.CreateReleaser(descriptor); 122var releaseDelegate = activatorProvider.CreateReleaser(descriptor);
Controllers\ControllerFactoryProviderTest.cs (3)
56var releaser = provider.CreateControllerReleaser(descriptor); 155Action<ControllerContext, object> expected = (_, __) => { }; 170var actual = provider.CreateControllerReleaser(descriptor);
Microsoft.AspNetCore.Mvc.Razor (5)
DependencyInjection\MvcRazorMvcBuilderExtensions.cs (1)
59Action<TTagHelper, ViewContext> initialize)
DependencyInjection\MvcRazorMvcCoreBuilderExtensions.cs (1)
104Action<TTagHelper, ViewContext> initialize)
RazorView.cs (1)
73internal Action<IRazorPage, ViewContext>? OnAfterPageActivated { get; set; }
TagHelperInitializerOfT.cs (2)
13private readonly Action<TTagHelper, ViewContext> _initializeDelegate; 19public TagHelperInitializer(Action<TTagHelper, ViewContext> action)
Microsoft.AspNetCore.Mvc.RazorPages (10)
Infrastructure\DefaultPageModelActivatorProvider.cs (2)
14private readonly Action<PageContext, object> _disposer = Dispose; 36public Action<PageContext, object>? CreateReleaser(CompiledPageActionDescriptor actionDescriptor)
Infrastructure\DefaultPageModelFactoryProvider.cs (1)
48public Action<PageContext, object>? CreateModelDisposer(CompiledPageActionDescriptor descriptor)
Infrastructure\ExecutorFactory.cs (2)
145private readonly Action<object, object?[]?> _thunk; 153_thunk = Expression.Lambda<Action<object, object?[]?>>(
Infrastructure\ServiceBasedPageModelActivatorProvider.cs (1)
34public Action<PageContext, object>? CreateReleaser(CompiledPageActionDescriptor descriptor)
IPageModelActivatorProvider.cs (2)
23Action<PageContext, object>? CreateReleaser(CompiledPageActionDescriptor descriptor); 32var releaser = CreateReleaser(descriptor);
IPageModelFactoryProvider.cs (2)
23Action<PageContext, object>? CreateModelDisposer(CompiledPageActionDescriptor descriptor); 32var releaser = CreateModelDisposer(descriptor);
Microsoft.AspNetCore.Mvc.RazorPages.Test (6)
Infrastructure\DefaultPageModelActivatorProviderTest.cs (2)
104var releaser = activator.CreateReleaser(actionDescriptor); 145var releaser = activator.CreateReleaser(actionDescriptor);
Infrastructure\DefaultPageModelFactoryProviderTest.cs (3)
35var disposer = factoryProvider.CreateModelDisposer(descriptor); 92Action<PageContext, object> disposer = (_, __) => { }; 98var actual = factoryProvider.CreateModelDisposer(descriptor);
Infrastructure\ServiceBasedPageModelActivatorProviderTest.cs (1)
135var releaser = activator.CreateReleaser(actionDescriptor);
Microsoft.AspNetCore.Mvc.Testing (3)
DeferredHostBuilder.cs (3)
56public IHostBuilder ConfigureAppConfiguration(Action<HostBuilderContext, IConfigurationBuilder> configureDelegate) 62public IHostBuilder ConfigureContainer<TContainerBuilder>(Action<HostBuilderContext, TContainerBuilder> configureDelegate) 77public IHostBuilder ConfigureServices(Action<HostBuilderContext, IServiceCollection> configureDelegate)
Microsoft.AspNetCore.Mvc.ViewFeatures (1)
ViewDataDictionaryControllerPropertyActivator.cs (1)
53public Action<ControllerContext, object> GetActivatorDelegate(ControllerActionDescriptor actionDescriptor)
Microsoft.AspNetCore.OpenApi (16)
src\Shared\ObjectMethodExecutor\ObjectMethodExecutor.cs (7)
26typeof(Action<object, Action>), // onCompletedMethod 27typeof(Action<object, Action>) // unsafeOnCompletedMethod 335var onCompletedFunc = Expression.Lambda<Action<object, Action>>( 343Action<object, Action>? unsafeOnCompletedFunc = null; 351unsafeOnCompletedFunc = Expression.Lambda<Action<object, Action>>( 380Expression.Constant(unsafeOnCompletedFunc, typeof(Action<object, Action>)));
src\Shared\ObjectMethodExecutor\ObjectMethodExecutorAwaitable.cs (9)
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) 111var underlyingMethodToUse = _unsafeOnCompletedMethod ?? _onCompletedMethod;
Microsoft.AspNetCore.Owin (17)
OwinEnvironment.cs (7)
262public FeatureMap(Type featureInterface, Func<object, object> getter, Action<object, object> setter) 274public FeatureMap(Type featureInterface, Func<object, object> getter, Func<object> defaultFactory, Action<object, object> setter) 287public FeatureMap(Type featureInterface, Func<object, object> getter, Func<object> defaultFactory, Action<object, object> setter, Func<object> featureFactory) 298private Action<object, object> Setter { get; set; } 375public FeatureMap(Func<TFeature, object> getter, Action<TFeature, object> setter) 386public FeatureMap(Func<TFeature, object> getter, Func<object> defaultFactory, Action<TFeature, object> setter) 398public FeatureMap(Func<TFeature, object> getter, Func<object> defaultFactory, Action<TFeature, object> setter, Func<TFeature> featureFactory)
OwinFeatureCollection.cs (4)
52var register = Prop<Action<Action<object>, object>>(OwinConstants.CommonKeys.OnSendingHeaders); 184var register = Prop<Action<Action<object>, object>>(OwinConstants.CommonKeys.OnSendingHeaders);
WebSockets\OwinWebSocketAcceptAdapter.cs (5)
11Action 33private readonly WebSocketAccept _owinWebSocketAccept; 39private OwinWebSocketAcceptAdapter(WebSocketAccept owinWebSocketAccept) 119if (environment.TryGetValue(OwinConstants.WebSocket.Accept, out accept) && accept is WebSocketAccept) 121var adapter = new OwinWebSocketAcceptAdapter((WebSocketAccept)accept);
WebSockets\WebSocketAcceptAdapter.cs (1)
11Action
Microsoft.AspNetCore.Routing (7)
src\Shared\PropertyHelper\PropertyHelper.cs (7)
45private Action<object, object?>? _valueSetter; 83public Action<object, object?> ValueSetter 272public static Action<object, object?> MakeFastPropertySetter(PropertyInfo propertyInfo) 295setMethod.CreateDelegate(typeof(Action<,>).MakeGenericType(typeInput, parameterType)); 300typeof(Action<object, object?>), propertySetterAsAction); 302return (Action<object, object?>)callPropertySetterDelegate; 387Action<TDeclaringType, TValue> setter,
Microsoft.AspNetCore.Routing.Abstractions (7)
src\Shared\PropertyHelper\PropertyHelper.cs (7)
45private Action<object, object?>? _valueSetter; 83public Action<object, object?> ValueSetter 272public static Action<object, object?> MakeFastPropertySetter(PropertyInfo propertyInfo) 295setMethod.CreateDelegate(typeof(Action<,>).MakeGenericType(typeInput, parameterType)); 300typeof(Action<object, object?>), propertySetterAsAction); 302return (Action<object, object?>)callPropertySetterDelegate; 387Action<TDeclaringType, TValue> setter,
Microsoft.AspNetCore.Server.HttpSys (2)
src\Shared\Buffers.MemoryPool\PinnedBlockMemoryPool.cs (2)
62private Action<object?, PinnedBlockMemoryPool>? _onPoolDisposed; 83public void OnPoolDisposed(Action<object?, PinnedBlockMemoryPool> onPoolDisposed, object? state = null)
Microsoft.AspNetCore.Server.IIS (2)
src\Shared\Buffers.MemoryPool\PinnedBlockMemoryPool.cs (2)
62private Action<object?, PinnedBlockMemoryPool>? _onPoolDisposed; 83public void OnPoolDisposed(Action<object?, PinnedBlockMemoryPool> onPoolDisposed, object? state = null)
Microsoft.AspNetCore.Server.IntegrationTesting.IIS (17)
IISDeployer.cs (2)
129protected override IEnumerable<Action<XElement, string>> GetWebConfigActions() 153foreach (var action in base.GetWebConfigActions())
IISDeployerBase.cs (6)
46foreach (var action in actions) 54protected virtual IEnumerable<Action<XElement, string>> GetWebConfigActions() 66foreach (var action in IISDeploymentParameters.WebConfigActionList) 72protected virtual IEnumerable<Action<XElement, string>> GetServerConfigActions() 74foreach (var action in IISDeploymentParameters.ServerConfigActionList) 82foreach (var action in GetServerConfigActions())
IISDeploymentParameterExtensions.cs (1)
21public static void AddServerConfigAction(this IISDeploymentParameters parameters, Action<XElement, string> action)
IISDeploymentParameters.cs (4)
40public IList<Action<XElement, string>> WebConfigActionList { get; } = new List<Action<XElement, string>>(); 42public IList<Action<XElement, string>> ServerConfigActionList { get; } = new List<Action<XElement, string>>();
IISExpressDeployer.cs (2)
341protected override IEnumerable<Action<XElement, string>> GetWebConfigActions() 369foreach (var action in base.GetWebConfigActions())
WebConfigHelpers.cs (2)
10public static Action<XElement, string> AddOrModifyAspNetCoreSection(string key, string value) 22public static Action<XElement, string> AddOrModifyHandlerSection(string key, string value)
Microsoft.AspNetCore.Server.Kestrel (2)
WebHostBuilderKestrelExtensions.cs (2)
151public static IWebHostBuilder UseKestrel(this IWebHostBuilder hostBuilder, Action<WebHostBuilderContext, KestrelServerOptions> configureOptions) 166public static IWebHostBuilder ConfigureKestrel(this IWebHostBuilder hostBuilder, Action<WebHostBuilderContext, KestrelServerOptions> configureOptions)
Microsoft.AspNetCore.Server.Kestrel.Core (7)
HttpsConnectionAdapterOptions.cs (2)
98public Action<ConnectionContext, SslServerAuthenticationOptions>? OnAuthenticate { get; set; } 106public Action<ConnectionContext, ReadOnlySequence<byte>>? TlsClientHelloBytesCallback { get; set; }
Internal\SniOptionsSelector.cs (1)
26private readonly Action<ConnectionContext, SslServerAuthenticationOptions>? _onAuthenticateCallback;
Middleware\TlsListener.cs (2)
12private readonly Action<ConnectionContext, ReadOnlySequence<byte>> _tlsClientHelloBytesCallback; 14public TlsListener(Action<ConnectionContext, ReadOnlySequence<byte>> tlsClientHelloBytesCallback)
src\Shared\Buffers.MemoryPool\PinnedBlockMemoryPool.cs (2)
62private Action<object?, PinnedBlockMemoryPool>? _onPoolDisposed; 83public void OnPoolDisposed(Action<object?, PinnedBlockMemoryPool> onPoolDisposed, object? state = null)
Microsoft.AspNetCore.Server.Kestrel.Microbenchmarks (2)
src\Servers\Kestrel\shared\test\Http3\Http3InMemory.cs (2)
143internal async Task WaitForConnectionErrorAsync<TException>(bool ignoreNonGoAwayFrames, long? expectedLastStreamId, Http3ErrorCode expectedErrorCode, Action<Type, string[]> matchExpectedErrorMessage = null, params string[] expectedErrorMessage) 176private void AssertConnectionError<TException>(Http3ErrorCode expectedErrorCode, Action<Type, string[]> matchExpectedErrorMessage = null, params string[] expectedErrorMessage) where TException : Exception
Microsoft.AspNetCore.Server.Kestrel.Transport.NamedPipes (2)
src\Shared\Buffers.MemoryPool\PinnedBlockMemoryPool.cs (2)
62private Action<object?, PinnedBlockMemoryPool>? _onPoolDisposed; 83public void OnPoolDisposed(Action<object?, PinnedBlockMemoryPool> onPoolDisposed, object? state = null)
Microsoft.AspNetCore.Server.Kestrel.Transport.Quic (2)
src\Shared\Buffers.MemoryPool\PinnedBlockMemoryPool.cs (2)
62private Action<object?, PinnedBlockMemoryPool>? _onPoolDisposed; 83public void OnPoolDisposed(Action<object?, PinnedBlockMemoryPool> onPoolDisposed, object? state = null)
Microsoft.AspNetCore.Shared.Tests (28)
PropertyHelperTest.cs (4)
441var publicPropertySetter = PropertyHelper.MakeFastPropertySetter(publicProperty); 442var protectedPropertySetter = PropertyHelper.MakeFastPropertySetter(protectedProperty); 460var propertySetter = PropertyHelper.MakeFastPropertySetter(property); 476var propertySetter = PropertyHelper.MakeFastPropertySetter(property);
src\Shared\ObjectMethodExecutor\ObjectMethodExecutor.cs (7)
26typeof(Action<object, Action>), // onCompletedMethod 27typeof(Action<object, Action>) // unsafeOnCompletedMethod 335var onCompletedFunc = Expression.Lambda<Action<object, Action>>( 343Action<object, Action>? unsafeOnCompletedFunc = null; 351unsafeOnCompletedFunc = Expression.Lambda<Action<object, Action>>( 380Expression.Constant(unsafeOnCompletedFunc, typeof(Action<object, Action>)));
src\Shared\ObjectMethodExecutor\ObjectMethodExecutorAwaitable.cs (9)
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) 111var underlyingMethodToUse = _unsafeOnCompletedMethod ?? _onCompletedMethod;
src\Shared\PropertyActivator\PropertyActivator.cs (1)
15private readonly Action<object, object> _fastPropertySetter;
src\Shared\PropertyHelper\PropertyHelper.cs (7)
45private Action<object, object?>? _valueSetter; 83public Action<object, object?> ValueSetter 272public static Action<object, object?> MakeFastPropertySetter(PropertyInfo propertyInfo) 295setMethod.CreateDelegate(typeof(Action<,>).MakeGenericType(typeInput, parameterType)); 300typeof(Action<object, object?>), propertySetterAsAction); 302return (Action<object, object?>)callPropertySetterDelegate; 387Action<TDeclaringType, TValue> setter,
Microsoft.AspNetCore.SignalR.Client.Core (1)
HubConnectionExtensions.cs (1)
65public static IDisposable On<T1, T2>(this HubConnection hubConnection, string methodName, Action<T1, T2> handler)
Microsoft.AspNetCore.SignalR.Client.Tests (2)
HubConnectionTests.Extensions.cs (2)
214private async Task InvokeOn(Action<HubConnection, TaskCompletionSource<object[]>> onAction, object[] args) 674private async Task<JToken> InvokeOnWithResult(Action<HubConnection, TaskCompletionSource<object[]>> onAction, object[] args)
Microsoft.AspNetCore.SignalR.Core (19)
src\Shared\ObjectMethodExecutor\ObjectMethodExecutor.cs (7)
26typeof(Action<object, Action>), // onCompletedMethod 27typeof(Action<object, Action>) // unsafeOnCompletedMethod 335var onCompletedFunc = Expression.Lambda<Action<object, Action>>( 343Action<object, Action>? unsafeOnCompletedFunc = null; 351unsafeOnCompletedFunc = Expression.Lambda<Action<object, Action>>( 380Expression.Constant(unsafeOnCompletedFunc, typeof(Action<object, Action>)));
src\Shared\ObjectMethodExecutor\ObjectMethodExecutorAwaitable.cs (9)
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) 111var underlyingMethodToUse = _unsafeOnCompletedMethod ?? _onCompletedMethod;
src\SignalR\common\Shared\ClientResultsManager.cs (3)
16private readonly ConcurrentDictionary<string, (Type Type, string ConnectionId, object Tcs, Action<object, CompletionMessage> Complete)> _pendingInvocations = new(); 41public void AddInvocation(string invocationId, (Type Type, string ConnectionId, object Tcs, Action<object, CompletionMessage> Complete) invocationInfo) 75public (Type Type, string ConnectionId, object Tcs, Action<object, CompletionMessage> Completion)? RemoveInvocation(string invocationId)
Microsoft.AspNetCore.SignalR.StackExchangeRedis (3)
src\SignalR\common\Shared\ClientResultsManager.cs (3)
16private readonly ConcurrentDictionary<string, (Type Type, string ConnectionId, object Tcs, Action<object, CompletionMessage> Complete)> _pendingInvocations = new(); 41public void AddInvocation(string invocationId, (Type Type, string ConnectionId, object Tcs, Action<object, CompletionMessage> Complete) invocationInfo) 75public (Type Type, string ConnectionId, object Tcs, Action<object, CompletionMessage> Completion)? RemoveInvocation(string invocationId)
Microsoft.AspNetCore.SignalR.StackExchangeRedis.Tests (9)
Docker.cs (1)
232private static void LogIfNotNull(Action<string, object[]> logger, string message, string data)
TestConnectionMultiplexer.cs (8)
239private readonly ConcurrentDictionary<RedisChannel, List<(int, Action<RedisChannel, RedisValue>)>> _subscriptions = 240new ConcurrentDictionary<RedisChannel, List<(int, Action<RedisChannel, RedisValue>)>>(); 264Action<RedisChannel, RedisValue> handler = (channel, value) => 272_subscriptions.AddOrUpdate(messageQueue.Channel, _ => new List<(int, Action<RedisChannel, RedisValue>)> { (subscriberId, handler) }, (_, list) => 357public void Subscribe(RedisChannel channel, Action<RedisChannel, RedisValue> handler, CommandFlags flags = CommandFlags.None) 362public Task SubscribeAsync(RedisChannel channel, Action<RedisChannel, RedisValue> handler, CommandFlags flags = CommandFlags.None) 380public void Unsubscribe(RedisChannel channel, Action<RedisChannel, RedisValue> handler = null, CommandFlags flags = CommandFlags.None) 397public Task UnsubscribeAsync(RedisChannel channel, Action<RedisChannel, RedisValue> handler = null, CommandFlags flags = CommandFlags.None)
Microsoft.AspNetCore.SpaServices.Extensions (1)
Prerendering\SpaPrerenderingOptions.cs (1)
42public Action<HttpContext, IDictionary<string, object>> SupplyData { get; set; }
Microsoft.AspNetCore.TestHost (1)
HttpContextBuilder.cs (1)
61internal void Configure(Action<HttpContext, PipeReader> configureContext)
Microsoft.AspNetCore.WebSockets.ConformanceTests (1)
Autobahn\Executable.cs (1)
64private void LogIfNotNull(Action<string, object[]> logger, string message, string data)
Microsoft.CodeAnalysis (39)
DiagnosticAnalyzer\AnalyzerDriver.cs (3)
474Action<Diagnostic, CancellationToken>? addNotCategorizedDiagnostic = null; 1955internal static Action<Diagnostic, CancellationToken> GetDiagnosticSink(Action<Diagnostic> addDiagnosticCore, Compilation compilation, AnalyzerOptions? analyzerOptions, SeverityFilter severityFilter, ConcurrentSet<string>? suppressedDiagnosticIds) 1979internal static Action<Diagnostic, DiagnosticAnalyzer, CancellationToken> GetDiagnosticSink(Action<Diagnostic, DiagnosticAnalyzer> addDiagnosticCore, Compilation compilation, AnalyzerOptions? analyzerOptions, SeverityFilter severityFilter, ConcurrentSet<string>? suppressedDiagnosticIds)
DiagnosticAnalyzer\AnalyzerExecutor.AnalyzerDiagnosticReporter.cs (2)
33Action<Diagnostic, CancellationToken>? addNonCategorizedDiagnostic, 72private Action<Diagnostic, CancellationToken>? _addNonCategorizedDiagnostic;
DiagnosticAnalyzer\AnalyzerExecutor.cs (4)
34private readonly Action<Diagnostic, CancellationToken>? _addNonCategorizedDiagnostic; 101Action<Diagnostic, CancellationToken>? addNonCategorizedDiagnostic, 133Action<Diagnostic, CancellationToken>? addNonCategorizedDiagnosticOpt, 1426Action<Diagnostic, CancellationToken>? addNonCategorizedDiagnostic,
SourceGeneration\IncrementalContexts.cs (9)
69public void RegisterSourceOutput<TSource>(IncrementalValueProvider<TSource> source, Action<SourceProductionContext, TSource> action) => RegisterSourceOutput(source.Node, action, IncrementalGeneratorOutputKind.Source, _sourceExtension); 71public void RegisterSourceOutput<TSource>(IncrementalValuesProvider<TSource> source, Action<SourceProductionContext, TSource> action) => RegisterSourceOutput(source.Node, action, IncrementalGeneratorOutputKind.Source, _sourceExtension); 73public void RegisterImplementationSourceOutput<TSource>(IncrementalValueProvider<TSource> source, Action<SourceProductionContext, TSource> action) => RegisterSourceOutput(source.Node, action, IncrementalGeneratorOutputKind.Implementation, _sourceExtension); 75public void RegisterImplementationSourceOutput<TSource>(IncrementalValuesProvider<TSource> source, Action<SourceProductionContext, TSource> action) => RegisterSourceOutput(source.Node, action, IncrementalGeneratorOutputKind.Implementation, _sourceExtension); 80public void RegisterHostOutput<TSource>(IncrementalValueProvider<TSource> source, Action<HostOutputProductionContext, TSource> action) => source.Node.RegisterOutput(new HostOutputNode<TSource>(source.Node, action.WrapUserAction(CatchAnalyzerExceptions))); 83public void RegisterHostOutput<TSource>(IncrementalValuesProvider<TSource> source, Action<HostOutputProductionContext, TSource> action) => source.Node.RegisterOutput(new HostOutputNode<TSource>(source.Node, action.WrapUserAction(CatchAnalyzerExceptions))); 93private void RegisterSourceOutput<TSource>(IIncrementalGeneratorNode<TSource> node, Action<SourceProductionContext, TSource> action, IncrementalGeneratorOutputKind kind, string sourceExt) 148/// Context passed to an incremental generator when it has registered an output via <see cref="IncrementalGeneratorInitializationContext.RegisterSourceOutput{TSource}(IncrementalValueProvider{TSource}, Action{SourceProductionContext, TSource})"/> 224/// Context passed to an incremental generator when it has registered an output via <see cref="IncrementalGeneratorInitializationContext.RegisterHostOutput{TSource}(IncrementalValuesProvider{TSource}, Action{HostOutputProductionContext, TSource})"/>
SourceGeneration\Nodes\IIncrementalGeneratorOutputNode.cs (6)
37/// A regular source output, registered via <see cref="IncrementalGeneratorInitializationContext.RegisterSourceOutput{TSource}(IncrementalValueProvider{TSource}, Action{SourceProductionContext, TSource})"/> 38/// or <see cref="IncrementalGeneratorInitializationContext.RegisterSourceOutput{TSource}(IncrementalValuesProvider{TSource}, Action{SourceProductionContext, TSource})"/> 48/// An Implementation only source output, registered via <see cref="IncrementalGeneratorInitializationContext.RegisterImplementationSourceOutput{TSource}(IncrementalValueProvider{TSource}, Action{SourceProductionContext, TSource})"/> 49/// or <see cref="IncrementalGeneratorInitializationContext.RegisterImplementationSourceOutput{TSource}(IncrementalValuesProvider{TSource}, Action{SourceProductionContext, TSource})"/> 54/// A host specific output, registered via <see cref="IncrementalGeneratorInitializationContext.RegisterHostOutput{TSource}(IncrementalValueProvider{TSource}, Action{HostOutputProductionContext, TSource})"/> 55/// or <see cref="IncrementalGeneratorInitializationContext.RegisterHostOutput{TSource}(IncrementalValuesProvider{TSource}, Action{HostOutputProductionContext, TSource})"/>
SourceGeneration\Nodes\PostInitOutputNode.cs (2)
12private readonly Action<IncrementalGeneratorPostInitializationContext, CancellationToken> _callback; 15public PostInitOutputNode(Action<IncrementalGeneratorPostInitializationContext, CancellationToken> callback, string embeddedAttributeDefinition)
SourceGeneration\Nodes\SyntaxInputNode.cs (2)
19private readonly Action<SyntaxInputNode, IIncrementalGeneratorOutputNode> _registerOutput; 23internal SyntaxInputNode(ISyntaxSelectionStrategy<T> inputNode, Action<SyntaxInputNode, IIncrementalGeneratorOutputNode> registerOutput, IEqualityComparer<T>? comparer = null, string? name = null)
SourceGeneration\UserFunction.cs (2)
82internal static Action<TInput, CancellationToken> WrapUserAction<TInput>(this Action<TInput> userAction, bool catchAnalyzerExceptions) 97internal static Action<TInput1, TInput2, CancellationToken> WrapUserAction<TInput1, TInput2>(this Action<TInput1, TInput2> userAction, bool catchAnalyzerExceptions)
src\Dependencies\CodeAnalysis.Debugging\CustomDebugInfoEncoder.cs (1)
208Action<T, BlobBuilder> recordSerializer)
src\Dependencies\PooledObjects\PooledDelegates.cs (8)
98public static Releaser GetPooledAction<T1, TArg>(Action<T1, TArg> unboundAction, TArg argument, out Action<T1> boundAction) 99=> GetPooledDelegate<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>>(unboundAction, argument, out boundAction); 102/// Gets an <see cref="Action{T1, T2}"/> delegate, which calls <paramref name="unboundAction"/> with the specified 132public static Releaser GetPooledAction<T1, T2, TArg>(Action<T1, T2, TArg> unboundAction, TArg argument, out Action<T1, T2> boundAction) 133=> GetPooledDelegate<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>>(unboundAction, argument, out boundAction); 391: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>> 398: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>> 400protected override Action<T1, T2> Bind()
Microsoft.CodeAnalysis.Analyzers (21)
src\Dependencies\PooledObjects\PooledDelegates.cs (8)
98public static Releaser GetPooledAction<T1, TArg>(Action<T1, TArg> unboundAction, TArg argument, out Action<T1> boundAction) 99=> GetPooledDelegate<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>>(unboundAction, argument, out boundAction); 102/// Gets an <see cref="Action{T1, T2}"/> delegate, which calls <paramref name="unboundAction"/> with the specified 132public static Releaser GetPooledAction<T1, T2, TArg>(Action<T1, T2, TArg> unboundAction, TArg argument, out Action<T1, T2> boundAction) 133=> GetPooledDelegate<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>>(unboundAction, argument, out boundAction); 391: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>> 398: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>> 400protected override Action<T1, T2> Bind()
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Extensions\ObjectWriterExtensions.cs (1)
13public static void WriteArray<T>(this ObjectWriter writer, ImmutableArray<T> values, Action<ObjectWriter, T> write)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\FlowAnalysis\SymbolUsageAnalysis\SymbolUsageAnalysis.BasicBlockAnalysisData.cs (1)
74public void ForEachCurrentWrite<TArg>(ISymbol symbol, Action<IOperation, TArg> action, TArg arg)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Formatting\Engine\AbstractFormatEngine.cs (6)
167var addIndentBlockOperations = _formattingRules.AddIndentBlockOperations; 168var addSuppressOperation = _formattingRules.AddSuppressOperations; 169var addAlignTokensOperations = _formattingRules.AddAlignTokensOperations; 170var addAnchorIndentationOperations = _formattingRules.AddAnchorIndentationOperations; 189private static void AddOperations<T>(SegmentedList<T> operations, List<T> scratch, SyntaxNode node, Action<List<T>, SyntaxNode> addOperations) 203private static void AddOperations<T>(SegmentedList<T> operations, ArrayBuilder<T> scratch, SyntaxNode node, Action<ArrayBuilder<T>, SyntaxNode> addOperations)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\NamingStyles\Serialization\NamingStylePreferencesEditorConfigSerializer.cs (1)
51Action<string, string> entryWriter,
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\ObjectPools\PooledObject.cs (2)
19private readonly Action<ObjectPool<T>, T> _releaser; 22public PooledObject(ObjectPool<T> pool, Func<ObjectPool<T>, T> allocator, Action<ObjectPool<T>, T> releaser) : this()
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Extensions\StringBuilderExtensions.cs (2)
21this StringBuilder builder, string separator, SeparatedSyntaxList<TNode> values, Action<TNode, StringBuilder> append) 37public static StringBuilder AppendJoinedValues<T>(this StringBuilder builder, string separator, ImmutableArray<T> values, Action<T, StringBuilder> append)
Microsoft.CodeAnalysis.AnalyzerUtilities (25)
src\Dependencies\PooledObjects\PooledDelegates.cs (8)
98public static Releaser GetPooledAction<T1, TArg>(Action<T1, TArg> unboundAction, TArg argument, out Action<T1> boundAction) 99=> GetPooledDelegate<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>>(unboundAction, argument, out boundAction); 102/// Gets an <see cref="Action{T1, T2}"/> delegate, which calls <paramref name="unboundAction"/> with the specified 132public static Releaser GetPooledAction<T1, T2, TArg>(Action<T1, T2, TArg> unboundAction, TArg argument, out Action<T1, T2> boundAction) 133=> GetPooledDelegate<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>>(unboundAction, argument, out boundAction); 391: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>> 398: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>> 400protected override Action<T1, T2> Bind()
src\RoslynAnalyzers\Utilities\FlowAnalysis\FlowAnalysis\Analysis\PointsToAnalysis\PointsToAnalysis.CorePointsToAnalysisDataDomain.cs (1)
59Action<AnalysisEntity, PointsToAnalysisData> resetAbstractValue)
src\RoslynAnalyzers\Utilities\FlowAnalysis\FlowAnalysis\Analysis\PointsToAnalysis\PointsToAnalysis.PointsToAnalysisDomain.cs (1)
27Action<AnalysisEntity, PointsToAnalysisData> resetAbstractValue,
src\RoslynAnalyzers\Utilities\FlowAnalysis\FlowAnalysis\Framework\DataFlow\PredicatedAnalysisData.cs (4)
222Action<DictionaryAnalysisData<TKey, TValue>, DictionaryAnalysisData<TKey, TValue>> applyPredicatedData) 278Action<DictionaryAnalysisData<TKey, TValue>, DictionaryAnalysisData<TKey, TValue>> applyPredicatedData) 327Action<DictionaryAnalysisData<TKey, TValue>, DictionaryAnalysisData<TKey, TValue>> applyPredicatedData) 349Action<DictionaryAnalysisData<TKey, TValue>, DictionaryAnalysisData<TKey, TValue>> applyPredicatedData)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Extensions\ObjectWriterExtensions.cs (1)
13public static void WriteArray<T>(this ObjectWriter writer, ImmutableArray<T> values, Action<ObjectWriter, T> write)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\FlowAnalysis\SymbolUsageAnalysis\SymbolUsageAnalysis.BasicBlockAnalysisData.cs (1)
74public void ForEachCurrentWrite<TArg>(ISymbol symbol, Action<IOperation, TArg> action, TArg arg)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Formatting\Engine\AbstractFormatEngine.cs (6)
167var addIndentBlockOperations = _formattingRules.AddIndentBlockOperations; 168var addSuppressOperation = _formattingRules.AddSuppressOperations; 169var addAlignTokensOperations = _formattingRules.AddAlignTokensOperations; 170var addAnchorIndentationOperations = _formattingRules.AddAnchorIndentationOperations; 189private static void AddOperations<T>(SegmentedList<T> operations, List<T> scratch, SyntaxNode node, Action<List<T>, SyntaxNode> addOperations) 203private static void AddOperations<T>(SegmentedList<T> operations, ArrayBuilder<T> scratch, SyntaxNode node, Action<ArrayBuilder<T>, SyntaxNode> addOperations)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\NamingStyles\Serialization\NamingStylePreferencesEditorConfigSerializer.cs (1)
51Action<string, string> entryWriter,
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\ObjectPools\PooledObject.cs (2)
19private readonly Action<ObjectPool<T>, T> _releaser; 22public PooledObject(ObjectPool<T> pool, Func<ObjectPool<T>, T> allocator, Action<ObjectPool<T>, T> releaser) : this()
Microsoft.CodeAnalysis.BannedApiAnalyzers (21)
src\Dependencies\PooledObjects\PooledDelegates.cs (8)
98public static Releaser GetPooledAction<T1, TArg>(Action<T1, TArg> unboundAction, TArg argument, out Action<T1> boundAction) 99=> GetPooledDelegate<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>>(unboundAction, argument, out boundAction); 102/// Gets an <see cref="Action{T1, T2}"/> delegate, which calls <paramref name="unboundAction"/> with the specified 132public static Releaser GetPooledAction<T1, T2, TArg>(Action<T1, T2, TArg> unboundAction, TArg argument, out Action<T1, T2> boundAction) 133=> GetPooledDelegate<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>>(unboundAction, argument, out boundAction); 391: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>> 398: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>> 400protected override Action<T1, T2> Bind()
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Extensions\ObjectWriterExtensions.cs (1)
13public static void WriteArray<T>(this ObjectWriter writer, ImmutableArray<T> values, Action<ObjectWriter, T> write)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\FlowAnalysis\SymbolUsageAnalysis\SymbolUsageAnalysis.BasicBlockAnalysisData.cs (1)
74public void ForEachCurrentWrite<TArg>(ISymbol symbol, Action<IOperation, TArg> action, TArg arg)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Formatting\Engine\AbstractFormatEngine.cs (6)
167var addIndentBlockOperations = _formattingRules.AddIndentBlockOperations; 168var addSuppressOperation = _formattingRules.AddSuppressOperations; 169var addAlignTokensOperations = _formattingRules.AddAlignTokensOperations; 170var addAnchorIndentationOperations = _formattingRules.AddAnchorIndentationOperations; 189private static void AddOperations<T>(SegmentedList<T> operations, List<T> scratch, SyntaxNode node, Action<List<T>, SyntaxNode> addOperations) 203private static void AddOperations<T>(SegmentedList<T> operations, ArrayBuilder<T> scratch, SyntaxNode node, Action<ArrayBuilder<T>, SyntaxNode> addOperations)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\NamingStyles\Serialization\NamingStylePreferencesEditorConfigSerializer.cs (1)
51Action<string, string> entryWriter,
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\ObjectPools\PooledObject.cs (2)
19private readonly Action<ObjectPool<T>, T> _releaser; 22public PooledObject(ObjectPool<T> pool, Func<ObjectPool<T>, T> allocator, Action<ObjectPool<T>, T> releaser) : this()
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Extensions\StringBuilderExtensions.cs (2)
21this StringBuilder builder, string separator, SeparatedSyntaxList<TNode> values, Action<TNode, StringBuilder> append) 37public static StringBuilder AppendJoinedValues<T>(this StringBuilder builder, string separator, ImmutableArray<T> values, Action<T, StringBuilder> append)
Microsoft.CodeAnalysis.CodeStyle (21)
src\Analyzers\Core\Analyzers\RemoveUnusedMembers\AbstractRemoveUnusedMembersDiagnosticAnalyzer.cs (2)
89protected virtual void HandleNamedTypeSymbolStart(SymbolStartAnalysisContext context, Action<ISymbol, ValueUsageInfo> onSymbolUsageFound) 230Action<ISymbol, ValueUsageInfo> onSymbolUsageFound = OnSymbolUsage;
src\Dependencies\PooledObjects\PooledDelegates.cs (8)
98public static Releaser GetPooledAction<T1, TArg>(Action<T1, TArg> unboundAction, TArg argument, out Action<T1> boundAction) 99=> GetPooledDelegate<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>>(unboundAction, argument, out boundAction); 102/// Gets an <see cref="Action{T1, T2}"/> delegate, which calls <paramref name="unboundAction"/> with the specified 132public static Releaser GetPooledAction<T1, T2, TArg>(Action<T1, T2, TArg> unboundAction, TArg argument, out Action<T1, T2> boundAction) 133=> GetPooledDelegate<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>>(unboundAction, argument, out boundAction); 391: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>> 398: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>> 400protected override Action<T1, T2> Bind()
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Extensions\ObjectWriterExtensions.cs (1)
13public static void WriteArray<T>(this ObjectWriter writer, ImmutableArray<T> values, Action<ObjectWriter, T> write)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\FlowAnalysis\SymbolUsageAnalysis\SymbolUsageAnalysis.BasicBlockAnalysisData.cs (1)
74public void ForEachCurrentWrite<TArg>(ISymbol symbol, Action<IOperation, TArg> action, TArg arg)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Formatting\Engine\AbstractFormatEngine.cs (6)
167var addIndentBlockOperations = _formattingRules.AddIndentBlockOperations; 168var addSuppressOperation = _formattingRules.AddSuppressOperations; 169var addAlignTokensOperations = _formattingRules.AddAlignTokensOperations; 170var addAnchorIndentationOperations = _formattingRules.AddAnchorIndentationOperations; 189private static void AddOperations<T>(SegmentedList<T> operations, List<T> scratch, SyntaxNode node, Action<List<T>, SyntaxNode> addOperations) 203private static void AddOperations<T>(SegmentedList<T> operations, ArrayBuilder<T> scratch, SyntaxNode node, Action<ArrayBuilder<T>, SyntaxNode> addOperations)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\NamingStyles\Serialization\NamingStylePreferencesEditorConfigSerializer.cs (1)
51Action<string, string> entryWriter,
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\ObjectPools\PooledObject.cs (2)
19private readonly Action<ObjectPool<T>, T> _releaser; 22public PooledObject(ObjectPool<T> pool, Func<ObjectPool<T>, T> allocator, Action<ObjectPool<T>, T> releaser) : this()
Microsoft.CodeAnalysis.CodeStyle.Fixes (2)
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Extensions\StringBuilderExtensions.cs (2)
21this StringBuilder builder, string separator, SeparatedSyntaxList<TNode> values, Action<TNode, StringBuilder> append) 37public static StringBuilder AppendJoinedValues<T>(this StringBuilder builder, string separator, ImmutableArray<T> values, Action<T, StringBuilder> append)
Microsoft.CodeAnalysis.Collections.Package (8)
src\Dependencies\PooledObjects\PooledDelegates.cs (8)
98public static Releaser GetPooledAction<T1, TArg>(Action<T1, TArg> unboundAction, TArg argument, out Action<T1> boundAction) 99=> GetPooledDelegate<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>>(unboundAction, argument, out boundAction); 102/// Gets an <see cref="Action{T1, T2}"/> delegate, which calls <paramref name="unboundAction"/> with the specified 132public static Releaser GetPooledAction<T1, T2, TArg>(Action<T1, T2, TArg> unboundAction, TArg argument, out Action<T1, T2> boundAction) 133=> GetPooledDelegate<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>>(unboundAction, argument, out boundAction); 391: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>> 398: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>> 400protected override Action<T1, T2> Bind()
Microsoft.CodeAnalysis.CSharp (35)
Binder\ExecutableCodeBinder.cs (2)
29private readonly Action<Binder, SyntaxNode> _binderUpdatedHandler; 32internal ExecutableCodeBinder(SyntaxNode root, Symbol memberSymbol, Binder next, Action<Binder, SyntaxNode> binderUpdatedHandler = null)
Binder\LocalBinderFactory.cs (1)
75Action<Binder, SyntaxNode> binderUpdatedHandler = null)
BoundTree\BoundExpression.cs (1)
734internal void VisitAllElements<T>(Action<BoundExpression, T> action, T args)
BoundTree\BoundNodeExtensions.cs (2)
111Action<BoundBinaryOperator, TArg>? binaryOperatorCallback = null) 154static void pushLeftNodes(BoundBinaryOperator binary, ArrayBuilder<BoundBinaryOperator> stack, TArg arg, Action<BoundBinaryOperator, TArg>? binaryOperatorCallback)
Declarations\DeclarationTreeBuilder.cs (1)
1021Action<HashSet<string>, TData> addMemberNames,
FlowAnalysis\NullableWalker.cs (26)
4090Action<int, TypeSymbol>? initializerCompletion = null; 4106Action<int, TypeSymbol>? initializerCompletion, 4135Action<int, TypeSymbol>? initializerCompletion, 4261private Action<int, TypeSymbol>? VisitObjectCreationInitializer(int containingSlot, TypeSymbol containingType, BoundObjectInitializerExpressionBase node, bool delayCompletionForType) 4264Action<int, TypeSymbol>? completion = null; 4311private Action<int, TypeSymbol>? VisitObjectElementInitializer(int containingSlot, TypeSymbol containingType, BoundAssignmentOperator node, bool delayCompletionForType) 4330Action<int, TypeSymbol>? visitMemberInitializer(int containingSlot, TypeSymbol containingType, BoundAssignmentOperator node, bool delayCompletionForType) 4349Action<int, Symbol>? initializationCompletion = null; 4369Action<int, TypeSymbol>? setAnalyzedNullability( 4373Action<int, Symbol>? initializationCompletion, 4391Action<int, TypeSymbol>? setAnalyzedNullabilityAsContinuation( 4395Action<int, Symbol>? initializationCompletion) 4406var result = setAnalyzedNullability(node, argumentResults, argumentsCompletion: null, initializationCompletion: null, delayCompletionForType: false); 4430Action<int, Symbol>? visitNestedInitializer(int containingSlot, TypeSymbol containingType, Symbol symbol, BoundObjectInitializerExpressionBase initializer, bool delayCompletionForType) 4435Action<int, TypeSymbol>? nestedCompletion = VisitObjectCreationInitializer(slot, GetTypeOrReturnType(symbol), initializer, delayCompletionForType); 4440Action<int, Symbol>? completeNestedInitializerAnalysis( 4441Symbol symbol, BoundObjectInitializerExpressionBase initializer, int slot, Action<int, TypeSymbol>? nestedCompletion, 4462Action<int, Symbol>? completeNestedInitializerAnalysisAsContinuation(BoundObjectInitializerExpressionBase initializer, Action<int, TypeSymbol>? nestedCompletion) 4472Action<int, Symbol>? visitMemberAssignment(BoundAssignmentOperator node, int containingSlot, Symbol symbol, bool delayCompletionForType, Func<TypeWithAnnotations, TypeWithState>? conversionCompletion = null) 4505Action<int, Symbol>? visitMemberAssignmentAsContinuation(BoundAssignmentOperator node, Func<TypeWithAnnotations, TypeWithState> conversionCompletion) 4509var result = visitMemberAssignment(node, containingSlot, symbol, delayCompletionForType: false, conversionCompletion); 4523private Action<int, TypeSymbol>? VisitCollectionElementInitializer(BoundCollectionElementInitializer node, TypeSymbol containingType, bool delayCompletionForType) 4556Action<int, TypeSymbol>? setUpdatedSymbol( 4583Action<int, TypeSymbol>? setUpdatedSymbolAsContinuation( 13305internal void ForEach<TArg>(Action<int, TArg> action, TArg arg)
Lowering\ClosureConversion\ClosureConversion.Analysis.Tree.cs (1)
219public static void VisitNestedFunctions(Scope scope, Action<Scope, NestedFunction> action)
Syntax\SyntaxExtensions.cs (1)
401internal static void VisitRankSpecifiers<TArg>(this TypeSyntax type, Action<ArrayRankSpecifierSyntax, TArg> action, in TArg argument)
Microsoft.CodeAnalysis.CSharp.CodeStyle (1)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\CSharp\Extensions\SyntaxNodeExtensions.cs (1)
762public static void ForEachMember<TArg>(this SyntaxNode? node, Action<MemberDeclarationSyntax, TArg> callback, TArg arg)
Microsoft.CodeAnalysis.CSharp.Emit3.UnitTests (6)
Attributes\AttributeTests.cs (1)
5614Action<FieldSymbol, string> VerifyAttributes = (field, value) =>
Attributes\AttributeTests_Tuples.cs (2)
867Action<TypeDefinition, string[]> verifyTupleConstraint = (def, tupleNames) => 967Action<TypeDefinition, string[]> verifyTupleImpls = (def, tupleNames) =>
Diagnostics\DiagnosticAnalyzerTests.cs (3)
775Action<Action<SyntaxNodeAnalysisContext>, ImmutableArray<SyntaxKind>> registerMethod = 789Action<Action<SyntaxNodeAnalysisContext>, ImmutableArray<SyntaxKind>> registerMethod = 797public void Initialize(Action<Action<SyntaxNodeAnalysisContext>, ImmutableArray<SyntaxKind>> registerSyntaxNodeAction)
Microsoft.CodeAnalysis.CSharp.Syntax.UnitTests (1)
Syntax\SyntaxNodeTests.cs (1)
4017private static void TestWithWindowsAndUnixEndOfLines(string inputText, string expectedText, Action<CompilationUnitSyntax, string> action)
Microsoft.CodeAnalysis.CSharp.Workspaces (1)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\CSharp\Extensions\SyntaxNodeExtensions.cs (1)
762public static void ForEachMember<TArg>(this SyntaxNode? node, Action<MemberDeclarationSyntax, TArg> callback, TArg arg)
Microsoft.CodeAnalysis.Debugging.Package (9)
CustomDebugInfoEncoder.cs (1)
208Action<T, BlobBuilder> recordSerializer)
src\Dependencies\PooledObjects\PooledDelegates.cs (8)
98public static Releaser GetPooledAction<T1, TArg>(Action<T1, TArg> unboundAction, TArg argument, out Action<T1> boundAction) 99=> GetPooledDelegate<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>>(unboundAction, argument, out boundAction); 102/// Gets an <see cref="Action{T1, T2}"/> delegate, which calls <paramref name="unboundAction"/> with the specified 132public static Releaser GetPooledAction<T1, T2, TArg>(Action<T1, T2, TArg> unboundAction, TArg argument, out Action<T1, T2> boundAction) 133=> GetPooledDelegate<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>>(unboundAction, argument, out boundAction); 391: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>> 398: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>> 400protected override Action<T1, T2> Bind()
Microsoft.CodeAnalysis.EditorFeatures (5)
Lightup\ISmartRenameSessionWrapper.cs (2)
34private static readonly Action<object, object>? s_renameContextImmutableListBuilderAddAccessor; 40private static readonly Action<object, string> s_onSuccess;
Lightup\LightupHelpers.cs (3)
166public static Action<T, TArg> CreateActionAccessor<T, TArg>(Type? type, string methodName, Type? argType) 217Expression.Lambda<Action<T, TArg>>( 538private static Action<T, TArg> CreateFallbackAction<T, TArg>()
Microsoft.CodeAnalysis.EditorFeatures.Test.Utilities (1)
CompleteStatement\AbstractCompleteStatementTests.cs (1)
97Action<IWpfTextView, EditorTestWorkspace> execute,
Microsoft.CodeAnalysis.ExpressionEvaluator.FunctionResolver.UnitTests (1)
FunctionResolverTestBase.cs (1)
180private static void AppendCommaSeparatedList<T>(StringBuilder builder, ImmutableArray<T> items, Action<StringBuilder, T> appendItem)
Microsoft.CodeAnalysis.Extensions.Package (8)
src\Dependencies\PooledObjects\PooledDelegates.cs (8)
98public static Releaser GetPooledAction<T1, TArg>(Action<T1, TArg> unboundAction, TArg argument, out Action<T1> boundAction) 99=> GetPooledDelegate<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>>(unboundAction, argument, out boundAction); 102/// Gets an <see cref="Action{T1, T2}"/> delegate, which calls <paramref name="unboundAction"/> with the specified 132public static Releaser GetPooledAction<T1, T2, TArg>(Action<T1, T2, TArg> unboundAction, TArg argument, out Action<T1, T2> boundAction) 133=> GetPooledDelegate<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>>(unboundAction, argument, out boundAction); 391: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>> 398: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>> 400protected override Action<T1, T2> Bind()
Microsoft.CodeAnalysis.ExternalAccess.OmniSharp (2)
CodeActions\OmniSharpCodeFixContextFactory.cs (2)
21Action<CodeAction, ImmutableArray<Diagnostic>> registerCodeFix, 28Action<CodeAction, TextSpan?> registerRefactoring,
Microsoft.CodeAnalysis.Features (16)
ChangeSignature\DelegateInvokeMethodReferenceFinder.cs (2)
72Action<Document, TData> processResult, 86Action<FinderLocation, TData> processResult,
CodeFixes\Suppression\AbstractSuppressionBatchFixAllProvider.cs (2)
119var registerCodeFix = GetRegisterCodeFixAction(fixAllState, onItemFound); 175private static Action<CodeAction, ImmutableArray<Diagnostic>> GetRegisterCodeFixAction(
Completion\Providers\SymbolCompletionItem.cs (3)
24private static readonly Action<ImmutableArray<ISymbol>, ArrayBuilder<KeyValuePair<string, string>>> s_addSymbolEncoding = AddSymbolEncoding; 25private static readonly Action<ImmutableArray<ISymbol>, ArrayBuilder<KeyValuePair<string, string>>> s_addSymbolInfo = AddSymbolInfo; 34Action<ImmutableArray<ISymbol>, ArrayBuilder<KeyValuePair<string, string>>> symbolEncoder,
EditAndContinue\DebuggingSession.cs (1)
969public void SetTelemetryLogger(Action<FunctionId, LogMessage> logger, Func<int> getNextId)
EditAndContinue\DebuggingSessionTelemetry.cs (1)
72public static void Log(Data data, Action<FunctionId, LogMessage> log, Func<int> getNextId)
ExtractInterface\AbstractExtractInterfaceService.cs (1)
60Action<string, NotificationSeverity> errorHandler,
GenerateConstructors\AbstractGenerateConstructorsCodeRefactoringProvider.cs (1)
154Action<CodeAction, TextSpan> registerSingleAction,
SolutionExplorer\ISolutionExplorerSymbolTreeItemProvider.cs (2)
38Action<TArgument, StringBuilder> append, 54Action<TNode, StringBuilder> append,
src\Analyzers\Core\Analyzers\RemoveUnusedMembers\AbstractRemoveUnusedMembersDiagnosticAnalyzer.cs (2)
89protected virtual void HandleNamedTypeSymbolStart(SymbolStartAnalysisContext context, Action<ISymbol, ValueUsageInfo> onSymbolUsageFound) 230Action<ISymbol, ValueUsageInfo> onSymbolUsageFound = OnSymbolUsage;
src\Dependencies\CodeAnalysis.Debugging\CustomDebugInfoEncoder.cs (1)
208Action<T, BlobBuilder> recordSerializer)
Microsoft.CodeAnalysis.InteractiveHost (11)
Interactive\Core\InteractiveHost.cs (3)
89internal event Action<char[], int>? OutputReceived; 90internal event Action<char[], int>? ErrorOutputReceived; 103internal event Action<Exception?, int?>? InteractiveHostProcessCreationFailed;
src\Dependencies\PooledObjects\PooledDelegates.cs (8)
98public static Releaser GetPooledAction<T1, TArg>(Action<T1, TArg> unboundAction, TArg argument, out Action<T1> boundAction) 99=> GetPooledDelegate<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>>(unboundAction, argument, out boundAction); 102/// Gets an <see cref="Action{T1, T2}"/> delegate, which calls <paramref name="unboundAction"/> with the specified 132public static Releaser GetPooledAction<T1, T2, TArg>(Action<T1, T2, TArg> unboundAction, TArg argument, out Action<T1, T2> boundAction) 133=> GetPooledDelegate<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>>(unboundAction, argument, out boundAction); 391: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>> 398: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>> 400protected override Action<T1, T2> Bind()
Microsoft.CodeAnalysis.LanguageServer.UnitTests (1)
Utilities\AbstractLanguageServerClientTests.TestLspClient.cs (1)
160Action<int, string> GetMessageLogger(string method)
Microsoft.CodeAnalysis.PerformanceSensitiveAnalyzers (21)
src\Dependencies\PooledObjects\PooledDelegates.cs (8)
98public static Releaser GetPooledAction<T1, TArg>(Action<T1, TArg> unboundAction, TArg argument, out Action<T1> boundAction) 99=> GetPooledDelegate<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>>(unboundAction, argument, out boundAction); 102/// Gets an <see cref="Action{T1, T2}"/> delegate, which calls <paramref name="unboundAction"/> with the specified 132public static Releaser GetPooledAction<T1, T2, TArg>(Action<T1, T2, TArg> unboundAction, TArg argument, out Action<T1, T2> boundAction) 133=> GetPooledDelegate<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>>(unboundAction, argument, out boundAction); 391: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>> 398: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>> 400protected override Action<T1, T2> Bind()
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Extensions\ObjectWriterExtensions.cs (1)
13public static void WriteArray<T>(this ObjectWriter writer, ImmutableArray<T> values, Action<ObjectWriter, T> write)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\FlowAnalysis\SymbolUsageAnalysis\SymbolUsageAnalysis.BasicBlockAnalysisData.cs (1)
74public void ForEachCurrentWrite<TArg>(ISymbol symbol, Action<IOperation, TArg> action, TArg arg)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Formatting\Engine\AbstractFormatEngine.cs (6)
167var addIndentBlockOperations = _formattingRules.AddIndentBlockOperations; 168var addSuppressOperation = _formattingRules.AddSuppressOperations; 169var addAlignTokensOperations = _formattingRules.AddAlignTokensOperations; 170var addAnchorIndentationOperations = _formattingRules.AddAnchorIndentationOperations; 189private static void AddOperations<T>(SegmentedList<T> operations, List<T> scratch, SyntaxNode node, Action<List<T>, SyntaxNode> addOperations) 203private static void AddOperations<T>(SegmentedList<T> operations, ArrayBuilder<T> scratch, SyntaxNode node, Action<ArrayBuilder<T>, SyntaxNode> addOperations)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\NamingStyles\Serialization\NamingStylePreferencesEditorConfigSerializer.cs (1)
51Action<string, string> entryWriter,
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\ObjectPools\PooledObject.cs (2)
19private readonly Action<ObjectPool<T>, T> _releaser; 22public PooledObject(ObjectPool<T> pool, Func<ObjectPool<T>, T> allocator, Action<ObjectPool<T>, T> releaser) : this()
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Extensions\StringBuilderExtensions.cs (2)
21this StringBuilder builder, string separator, SeparatedSyntaxList<TNode> values, Action<TNode, StringBuilder> append) 37public static StringBuilder AppendJoinedValues<T>(this StringBuilder builder, string separator, ImmutableArray<T> values, Action<T, StringBuilder> append)
Microsoft.CodeAnalysis.PooledObjects.Package (8)
PooledDelegates.cs (8)
98public static Releaser GetPooledAction<T1, TArg>(Action<T1, TArg> unboundAction, TArg argument, out Action<T1> boundAction) 99=> GetPooledDelegate<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>>(unboundAction, argument, out boundAction); 102/// Gets an <see cref="Action{T1, T2}"/> delegate, which calls <paramref name="unboundAction"/> with the specified 132public static Releaser GetPooledAction<T1, T2, TArg>(Action<T1, T2, TArg> unboundAction, TArg argument, out Action<T1, T2> boundAction) 133=> GetPooledDelegate<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>>(unboundAction, argument, out boundAction); 391: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>> 398: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>> 400protected override Action<T1, T2> Bind()
Microsoft.CodeAnalysis.PublicApiAnalyzers (19)
src\Dependencies\PooledObjects\PooledDelegates.cs (8)
98public static Releaser GetPooledAction<T1, TArg>(Action<T1, TArg> unboundAction, TArg argument, out Action<T1> boundAction) 99=> GetPooledDelegate<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>>(unboundAction, argument, out boundAction); 102/// Gets an <see cref="Action{T1, T2}"/> delegate, which calls <paramref name="unboundAction"/> with the specified 132public static Releaser GetPooledAction<T1, T2, TArg>(Action<T1, T2, TArg> unboundAction, TArg argument, out Action<T1, T2> boundAction) 133=> GetPooledDelegate<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>>(unboundAction, argument, out boundAction); 391: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>> 398: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>> 400protected override Action<T1, T2> Bind()
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Extensions\ObjectWriterExtensions.cs (1)
13public static void WriteArray<T>(this ObjectWriter writer, ImmutableArray<T> values, Action<ObjectWriter, T> write)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\FlowAnalysis\SymbolUsageAnalysis\SymbolUsageAnalysis.BasicBlockAnalysisData.cs (1)
74public void ForEachCurrentWrite<TArg>(ISymbol symbol, Action<IOperation, TArg> action, TArg arg)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Formatting\Engine\AbstractFormatEngine.cs (6)
167var addIndentBlockOperations = _formattingRules.AddIndentBlockOperations; 168var addSuppressOperation = _formattingRules.AddSuppressOperations; 169var addAlignTokensOperations = _formattingRules.AddAlignTokensOperations; 170var addAnchorIndentationOperations = _formattingRules.AddAnchorIndentationOperations; 189private static void AddOperations<T>(SegmentedList<T> operations, List<T> scratch, SyntaxNode node, Action<List<T>, SyntaxNode> addOperations) 203private static void AddOperations<T>(SegmentedList<T> operations, ArrayBuilder<T> scratch, SyntaxNode node, Action<ArrayBuilder<T>, SyntaxNode> addOperations)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\NamingStyles\Serialization\NamingStylePreferencesEditorConfigSerializer.cs (1)
51Action<string, string> entryWriter,
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\ObjectPools\PooledObject.cs (2)
19private readonly Action<ObjectPool<T>, T> _releaser; 22public PooledObject(ObjectPool<T> pool, Func<ObjectPool<T>, T> allocator, Action<ObjectPool<T>, T> releaser) : this()
Microsoft.CodeAnalysis.ResxSourceGenerator (19)
src\Dependencies\PooledObjects\PooledDelegates.cs (8)
98public static Releaser GetPooledAction<T1, TArg>(Action<T1, TArg> unboundAction, TArg argument, out Action<T1> boundAction) 99=> GetPooledDelegate<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>>(unboundAction, argument, out boundAction); 102/// Gets an <see cref="Action{T1, T2}"/> delegate, which calls <paramref name="unboundAction"/> with the specified 132public static Releaser GetPooledAction<T1, T2, TArg>(Action<T1, T2, TArg> unboundAction, TArg argument, out Action<T1, T2> boundAction) 133=> GetPooledDelegate<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>>(unboundAction, argument, out boundAction); 391: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>> 398: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>> 400protected override Action<T1, T2> Bind()
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Extensions\ObjectWriterExtensions.cs (1)
13public static void WriteArray<T>(this ObjectWriter writer, ImmutableArray<T> values, Action<ObjectWriter, T> write)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\FlowAnalysis\SymbolUsageAnalysis\SymbolUsageAnalysis.BasicBlockAnalysisData.cs (1)
74public void ForEachCurrentWrite<TArg>(ISymbol symbol, Action<IOperation, TArg> action, TArg arg)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Formatting\Engine\AbstractFormatEngine.cs (6)
167var addIndentBlockOperations = _formattingRules.AddIndentBlockOperations; 168var addSuppressOperation = _formattingRules.AddSuppressOperations; 169var addAlignTokensOperations = _formattingRules.AddAlignTokensOperations; 170var addAnchorIndentationOperations = _formattingRules.AddAnchorIndentationOperations; 189private static void AddOperations<T>(SegmentedList<T> operations, List<T> scratch, SyntaxNode node, Action<List<T>, SyntaxNode> addOperations) 203private static void AddOperations<T>(SegmentedList<T> operations, ArrayBuilder<T> scratch, SyntaxNode node, Action<ArrayBuilder<T>, SyntaxNode> addOperations)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\NamingStyles\Serialization\NamingStylePreferencesEditorConfigSerializer.cs (1)
51Action<string, string> entryWriter,
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\ObjectPools\PooledObject.cs (2)
19private readonly Action<ObjectPool<T>, T> _releaser; 22public PooledObject(ObjectPool<T> pool, Func<ObjectPool<T>, T> allocator, Action<ObjectPool<T>, T> releaser) : this()
Microsoft.CodeAnalysis.Test.Utilities (1)
Compilation\TestDesktopStrongNameProvider.cs (1)
24internal Action<StrongNameKeys, string> SignFileFunc { get; set; }
Microsoft.CodeAnalysis.Threading.Package (8)
src\Dependencies\PooledObjects\PooledDelegates.cs (8)
98public static Releaser GetPooledAction<T1, TArg>(Action<T1, TArg> unboundAction, TArg argument, out Action<T1> boundAction) 99=> GetPooledDelegate<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>>(unboundAction, argument, out boundAction); 102/// Gets an <see cref="Action{T1, T2}"/> delegate, which calls <paramref name="unboundAction"/> with the specified 132public static Releaser GetPooledAction<T1, T2, TArg>(Action<T1, T2, TArg> unboundAction, TArg argument, out Action<T1, T2> boundAction) 133=> GetPooledDelegate<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>>(unboundAction, argument, out boundAction); 391: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>> 398: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>> 400protected override Action<T1, T2> Bind()
Microsoft.CodeAnalysis.UnitTests (4)
AnalyzerAssemblyLoaderTests.cs (2)
91Action<AnalyzerAssemblyLoader, AssemblyLoadTestFixture> testAction, 135Action<AnalyzerAssemblyLoader, AssemblyLoadTestFixture> testAction)
Collections\List\IEnumerable.Generic.Tests.cs (1)
152Action<IEnumerator<T>, T[]> testCode,
MetadataReferences\ModuleMetadataTests.cs (1)
395public Action<long, SeekOrigin> OnSeek;
Microsoft.CodeAnalysis.Workspaces (159)
CodeFixes\CodeFixContext.cs (5)
21private readonly Action<CodeAction, ImmutableArray<Diagnostic>> _registerCodeFix; 89Action<CodeAction, ImmutableArray<Diagnostic>> registerCodeFix, 120Action<CodeAction, ImmutableArray<Diagnostic>> registerCodeFix, 147Action<CodeAction, ImmutableArray<Diagnostic>> registerCodeFix, 171Action<CodeAction, ImmutableArray<Diagnostic>> registerCodeFix,
CodeFixes\FixAllOccurrences\BatchFixAllProvider.cs (2)
154var action = GetRegisterCodeFixAction(fixAllContext.CodeActionEquivalenceKey, codeActions); 229private static Action<CodeAction, ImmutableArray<Diagnostic>> GetRegisterCodeFixAction(
CodeRefactorings\CodeRefactoringContext.cs (2)
56private readonly Action<CodeAction, TextSpan?> _registerRefactoring; 87Action<CodeAction, TextSpan?> registerRefactoring,
FindSymbols\FindReferences\Finders\AbstractMemberScopedReferenceFinder.cs (3)
32Action<Document, TData> processResult, 55Action<FinderLocation, TData> processResult, 104Action<FinderLocation, TData> processResult,
FindSymbols\FindReferences\Finders\AbstractReferenceFinder.cs (33)
35ISymbol symbol, HashSet<string>? globalAliases, Project project, IImmutableSet<Document>? documents, Action<Document, TData> processResult, TData processResultData, FindReferencesSearchOptions options, CancellationToken cancellationToken); 38ISymbol symbol, FindReferencesDocumentState state, Action<FinderLocation, TData> processResult, TData processResultData, FindReferencesSearchOptions options, CancellationToken cancellationToken); 89Action<Document, TData> processResult, 120Action<Document, TData> processResult, 141Project project, IImmutableSet<Document>? documents, Action<Document, TData> processResult, TData processResultData, CancellationToken cancellationToken) 151Action<Document, TData> processResult, 169Action<FinderLocation, TData> processResult, 184Action<FinderLocation, TData> processResult, 247Action<FinderLocation, TData> processResult, 259Action<FinderLocation, TData> processResult, 288Action<FinderLocation, TData> processResult, 310Action<FinderLocation, TData> processResult, 334Action<Document, TData> processResult, 349Action<Document, TData> processResult, 362protected static Task FindDocumentsWithForEachStatementsAsync<TData>(Project project, IImmutableSet<Document>? documents, Action<Document, TData> processResult, TData processResultData, CancellationToken cancellationToken) 365protected static Task FindDocumentsWithUsingStatementsAsync<TData>(Project project, IImmutableSet<Document>? documents, Action<Document, TData> processResult, TData processResultData, CancellationToken cancellationToken) 372SyntaxNode node, FindReferencesDocumentState state, Action<FinderLocation, TData> processResult, TData processResultData); 378Action<FinderLocation, TData> processResult, 396Action<FinderLocation, TData> processResult, 404SyntaxNode node, FindReferencesDocumentState state, Action<FinderLocation, TData> processResult, TData processResultData) 432Action<FinderLocation, TData> processResult, 443SyntaxNode node, FindReferencesDocumentState state, Action<FinderLocation, TData> processResult, TData processResultData) 475Action<FinderLocation, TData> processResult, 486SyntaxNode node, FindReferencesDocumentState state, Action<FinderLocation, TData> processResult, TData processResultData) 513Action<FinderLocation, TData> processResult, 524SyntaxNode node, FindReferencesDocumentState state, Action<FinderLocation, TData> processResult, TData processResultData) 544Action<FinderLocation, TData> processResult, 555SyntaxNode node, FindReferencesDocumentState state, Action<FinderLocation, TData> processResult, TData processResultData) 661Action<Document, TData> processResult, TData processResultData, 666Action<FinderLocation, TData> processResult, TData processResultData, 685IImmutableSet<Document>? documents, Action<Document, TData> processResult, 695ISymbol symbol, FindReferencesDocumentState state, Action<FinderLocation, TData> processResult, TData processResultData, FindReferencesSearchOptions options, CancellationToken cancellationToken) 721TSymbol symbol, FindReferencesDocumentState state, Action<FinderLocation, TData> processResult, TData processResultData, CancellationToken cancellationToken)
FindSymbols\FindReferences\Finders\AbstractReferenceFinder_GlobalSuppressions.cs (1)
55Action<FinderLocation, TData> processResult,
FindSymbols\FindReferences\Finders\AbstractTypeParameterSymbolReferenceFinder.cs (2)
18Action<FinderLocation, TData> processResult, 56Action<FinderLocation, TData> processResult,
FindSymbols\FindReferences\Finders\ConstructorInitializerSymbolReferenceFinder.cs (2)
25Action<Document, TData> processResult, 68Action<FinderLocation, TData> processResult,
FindSymbols\FindReferences\Finders\ConstructorSymbolReferenceFinder.cs (11)
60Action<Document, TData> processResult, 93private static Task FindDocumentsWithImplicitObjectCreationExpressionAsync<TData>(Project project, IImmutableSet<Document>? documents, Action<Document, TData> processResult, TData processResultData, CancellationToken cancellationToken) 100Action<Document, TData> processResult, 117Action<FinderLocation, TData> processResult, 151IMethodSymbol methodSymbol, FindReferencesDocumentState state, Action<FinderLocation, TData> processResult, TData processResultData, string name, string alias, CancellationToken cancellationToken) 171Action<FinderLocation, TData> processResult, 185Action<FinderLocation, TData> processResult, 196Action<FinderLocation, TData> processResult, 217Action<FinderLocation, TData> processResult, 228Action<FinderLocation, TData> processResult, 289Action<FinderLocation, TData> processResult,
FindSymbols\FindReferences\Finders\DestructorSymbolReferenceFinder.cs (2)
23Action<Document, TData> processResult, 34Action<FinderLocation, TData> processResult,
FindSymbols\FindReferences\Finders\DynamicTypeSymbolReferenceFinder.cs (2)
30Action<Document, TData> processResult, 42Action<FinderLocation, TData> processResult,
FindSymbols\FindReferences\Finders\EventSymbolReferenceFinder.cs (2)
54Action<Document, TData> processResult, 66Action<FinderLocation, TData> processResult,
FindSymbols\FindReferences\Finders\ExplicitConversionSymbolReferenceFinder.cs (2)
31Action<Document, TData> processResult, 65Action<FinderLocation, TData> processResult,
FindSymbols\FindReferences\Finders\ExplicitInterfaceMethodReferenceFinder.cs (2)
23Action<Document, TData> processResult, 35Action<FinderLocation, TData> processResult,
FindSymbols\FindReferences\Finders\FieldSymbolReferenceFinder.cs (2)
34Action<Document, TData> processResult, 46Action<FinderLocation, TData> processResult,
FindSymbols\FindReferences\Finders\IReferenceFinder.cs (2)
56Action<Document, TData> processResult, TData processResultData, 69Action<FinderLocation, TData> processResult,
FindSymbols\FindReferences\Finders\MethodTypeParameterSymbolReferenceFinder.cs (1)
46Action<Document, TData> processResult,
FindSymbols\FindReferences\Finders\NamedTypeSymbolReferenceFinder.cs (8)
58Action<Document, TData> processResult, 85Action<Document, TData> processResult, 111Action<FinderLocation, TData> processResult, 144Action<FinderLocation, TData> processResult, 159INamedTypeSymbol namedType, FindReferencesDocumentState state, Action<FinderLocation, TData> processResult, TData processResultData, string alias, CancellationToken cancellationToken) 180Action<FinderLocation, TData> processResult, 195Action<FinderLocation, TData> processResult, 232Action<FinderLocation, TData> processResult,
FindSymbols\FindReferences\Finders\NamespaceSymbolReferenceFinder.cs (4)
31Action<Document, TData> processResult, 56Action<FinderLocation, TData> processResult, 113Action<FinderLocation, TData> processResult, 126Action<FinderLocation, TData> processResult,
FindSymbols\FindReferences\Finders\OperatorSymbolReferenceFinder.cs (3)
26Action<Document, TData> processResult, 40Action<Document, TData> processResult, 54Action<FinderLocation, TData> processResult,
FindSymbols\FindReferences\Finders\OrdinaryMethodReferenceFinder.cs (7)
52Action<Document, TData> processResult, 93private static Task FindDocumentsWithDeconstructionAsync<TData>(Project project, IImmutableSet<Document>? documents, Action<Document, TData> processResult, TData processResultData, CancellationToken cancellationToken) 96private static Task FindDocumentsWithAwaitExpressionAsync<TData>(Project project, IImmutableSet<Document>? documents, Action<Document, TData> processResult, TData processResultData, CancellationToken cancellationToken) 99private static Task FindDocumentsWithCollectionInitializersAsync<TData>(Project project, IImmutableSet<Document>? documents, Action<Document, TData> processResult, TData processResultData, CancellationToken cancellationToken) 121Action<FinderLocation, TData> processResult, 151Action<FinderLocation, TData> processResult, 161Action<FinderLocation, TData> processResult,
FindSymbols\FindReferences\Finders\ParameterSymbolReferenceFinder.cs (2)
29Action<Document, TData> processResult, 45Action<FinderLocation, TData> processResult,
FindSymbols\FindReferences\Finders\PreprocessingSymbolReferenceFinder.cs (2)
24Action<Document, TData> processResult, 41Action<FinderLocation, TData> processResult,
FindSymbols\FindReferences\Finders\PropertyAccessorSymbolReferenceFinder.cs (2)
37Action<Document, TData> processResult, 66Action<FinderLocation, TData> processResult,
FindSymbols\FindReferences\Finders\PropertySymbolReferenceFinder.cs (5)
112Action<Document, TData> processResult, 137Action<FinderLocation, TData> processResult, 175Project project, IImmutableSet<Document>? documents, Action<Document, TData> processResult, TData processResultData, CancellationToken cancellationToken) 182Project project, IImmutableSet<Document>? documents, Action<Document, TData> processResult, TData processResultData, CancellationToken cancellationToken) 191Action<FinderLocation, TData> processResult,
FindSymbols\FindReferences\Finders\TypeParameterSymbolReferenceFinder.cs (1)
23Action<Document, TData> processResult,
FindSymbols\FindReferences\StandardCallbacks.cs (2)
13public static readonly Action<T, HashSet<T>> AddToHashSet = 16public static readonly Action<T, ArrayBuilder<T>> AddToArrayBuilder =
Log\KeyValueLogMessage.cs (6)
73private Action<Dictionary<string, object?>, TArgs> _propertySetter = null!; 94LogType kind, Action<Dictionary<string, object?>, TArgs> propertySetter, TArgs args, LogLevel logLevel) 103Action<Dictionary<string, object?>, TArgs> propertySetter, TArgs args, LogLevel logLevel) 112LogType kind, Action<Dictionary<string, object?>, TArgs> propertySetter, TArgs args, LogLevel logLevel) 136public static KeyValueLogMessage Create<TArgs>(Action<Dictionary<string, object?>, TArgs> propertySetter, TArgs args, LogLevel logLevel = LogLevel.Information) 139public static KeyValueLogMessage Create<TArgs>(LogType kind, Action<Dictionary<string, object?>, TArgs> propertySetter, TArgs args, LogLevel logLevel = LogLevel.Information)
Shared\Utilities\XmlFragmentParser.cs (2)
38public static void ParseFragment<TArg>(string xmlFragment, Action<XmlReader, TArg> callback, TArg arg) 56private void ParseInternal<TArg>(string text, Action<XmlReader, TArg> callback, TArg arg)
src\Dependencies\PooledObjects\PooledDelegates.cs (8)
98public static Releaser GetPooledAction<T1, TArg>(Action<T1, TArg> unboundAction, TArg argument, out Action<T1> boundAction) 99=> GetPooledDelegate<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>>(unboundAction, argument, out boundAction); 102/// Gets an <see cref="Action{T1, T2}"/> delegate, which calls <paramref name="unboundAction"/> with the specified 132public static Releaser GetPooledAction<T1, T2, TArg>(Action<T1, T2, TArg> unboundAction, TArg argument, out Action<T1, T2> boundAction) 133=> GetPooledDelegate<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>>(unboundAction, argument, out boundAction); 391: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>> 398: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>> 400protected override Action<T1, T2> Bind()
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Extensions\ObjectWriterExtensions.cs (1)
13public static void WriteArray<T>(this ObjectWriter writer, ImmutableArray<T> values, Action<ObjectWriter, T> write)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\FlowAnalysis\SymbolUsageAnalysis\SymbolUsageAnalysis.BasicBlockAnalysisData.cs (1)
74public void ForEachCurrentWrite<TArg>(ISymbol symbol, Action<IOperation, TArg> action, TArg arg)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Formatting\Engine\AbstractFormatEngine.cs (6)
167var addIndentBlockOperations = _formattingRules.AddIndentBlockOperations; 168var addSuppressOperation = _formattingRules.AddSuppressOperations; 169var addAlignTokensOperations = _formattingRules.AddAlignTokensOperations; 170var addAnchorIndentationOperations = _formattingRules.AddAnchorIndentationOperations; 189private static void AddOperations<T>(SegmentedList<T> operations, List<T> scratch, SyntaxNode node, Action<List<T>, SyntaxNode> addOperations) 203private static void AddOperations<T>(SegmentedList<T> operations, ArrayBuilder<T> scratch, SyntaxNode node, Action<ArrayBuilder<T>, SyntaxNode> addOperations)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\NamingStyles\Serialization\NamingStylePreferencesEditorConfigSerializer.cs (1)
51Action<string, string> entryWriter,
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\ObjectPools\PooledObject.cs (2)
19private readonly Action<ObjectPool<T>, T> _releaser; 22public PooledObject(ObjectPool<T> pool, Func<ObjectPool<T>, T> allocator, Action<ObjectPool<T>, T> releaser) : this()
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Extensions\StringBuilderExtensions.cs (2)
21this StringBuilder builder, string separator, SeparatedSyntaxList<TNode> values, Action<TNode, StringBuilder> append) 37public static StringBuilder AppendJoinedValues<T>(this StringBuilder builder, string separator, ImmutableArray<T> values, Action<T, StringBuilder> append)
Workspace\ProjectSystem\ProjectSystemProject.BatchingDocumentCollection.cs (4)
67private readonly Action<Workspace, DocumentInfo> _documentAddAction; 68private readonly Action<Workspace, DocumentId> _documentRemoveAction; 86Action<Workspace, DocumentInfo> documentAddAction, 87Action<Workspace, DocumentId> documentRemoveAction,
Workspace\Solution\Checksum_Factory.cs (1)
78public static Checksum Create<T>(T @object, Action<T, ObjectWriter> writeObject)
Workspace\Solution\SolutionCompilationState.cs (3)
217Action<ImmutableSegmentedDictionary<ProjectId, ICompilationTracker>.Builder, TArg> modifyNewTrackerInfo, 245Action<ImmutableSegmentedDictionary<ProjectId, ICompilationTracker>.Builder, TArg> modifyNewTrackerInfo, 277Action<ImmutableSegmentedDictionary<ProjectId, ICompilationTracker>.Builder, TArgModifyNewTrackerInfo> modifyNewTrackerInfo,
Workspace\Workspace.cs (8)
200/// <inheritdoc cref="SetCurrentSolution(Func{Solution, Solution}, Func{Solution, Solution, ValueTuple{WorkspaceChangeKind, ProjectId?, DocumentId?}}, Action{Solution, Solution}?, Action{Solution, Solution}?)"/> 206Action<Solution, Solution>? onBeforeUpdate = null, 207Action<Solution, Solution>? onAfterUpdate = null) 233Action<Solution, Solution>? onBeforeUpdate = null, 234Action<Solution, Solution>? onAfterUpdate = null) 253Action<Solution, Solution>? onBeforeUpdate, 254Action<Solution, Solution>? onAfterUpdate,
Workspace\Workspace_Editor.cs (2)
555Action<Solution, DocumentId> checkTextDocumentIsInSolution, 749Action<Solution, DocumentId> checkTextDocumentIsInSolution,
Microsoft.CodeAnalysis.Workspaces.MSBuild.BuildHost (10)
src\Dependencies\PooledObjects\PooledDelegates.cs (8)
98public static Releaser GetPooledAction<T1, TArg>(Action<T1, TArg> unboundAction, TArg argument, out Action<T1> boundAction) 99=> GetPooledDelegate<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>>(unboundAction, argument, out boundAction); 102/// Gets an <see cref="Action{T1, T2}"/> delegate, which calls <paramref name="unboundAction"/> with the specified 132public static Releaser GetPooledAction<T1, T2, TArg>(Action<T1, T2, TArg> unboundAction, TArg argument, out Action<T1, T2> boundAction) 133=> GetPooledDelegate<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>>(unboundAction, argument, out boundAction); 391: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>> 398: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>> 400protected override Action<T1, T2> Bind()
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\ObjectPools\PooledObject.cs (2)
19private readonly Action<ObjectPool<T>, T> _releaser; 22public PooledObject(ObjectPool<T> pool, Func<ObjectPool<T>, T> allocator, Action<ObjectPool<T>, T> releaser) : this()
Microsoft.CodeAnalysis.Workspaces.MSBuild.UnitTests (1)
SolutionGeneration.cs (1)
320Action<T, XElement> elementModifier = null)
Microsoft.CodeAnalysis.Workspaces.UnitTests (4)
ObjectSerializationTests.cs (3)
55private static T RoundTrip<T>(T value, Action<ObjectWriter, T> writeAction, Func<ObjectReader, T> readAction, bool recursive) 69private static void TestRoundTrip<T>(T value, Action<ObjectWriter, T> writeAction, Func<ObjectReader, T> readAction, bool recursive) 75private static void TestRoundTrip<T>(T value, Action<ObjectWriter, T> writeAction, Func<ObjectReader, T> readAction)
UtilityTest\AsyncLazyTests.cs (1)
139private static void GetValueOrGetValueAsyncThrowsCorrectExceptionDuringCancellation(Action<AsyncLazy<object>, CancellationToken> doGetValue, bool includeSynchronousComputation)
Microsoft.Data.Analysis.Tests (2)
test\Microsoft.ML.TestFramework\GlobalBase.cs (2)
25var prev = Contracts.SetAssertHandler(AssertHandler); 64var prev = Contracts.SetAssertHandler(null);
Microsoft.DotNet.Internal.SymbolHelper (1)
ScopedTracer.cs (1)
27private void LogToMethod(Action<string, object[]> logMethod, string format, object[] arguments) => logMethod(ScopedMessage(format), arguments);
Microsoft.DotNet.RemoteExecutor (1)
RemoteExecutor.cs (1)
143public static RemoteInvokeHandle Invoke(Action<string, string> method, string arg1, string arg2,
Microsoft.DotNet.SwaggerGenerator.CodeGenerator (9)
HelperFactory.cs (2)
137new ProvidedParameter("template", typeof(Action<TextWriter, object>), Expression.MakeMemberAccess(optionsParameter, typeof(HelperOptions).GetProperty("Template"))), 138new ProvidedParameter("inverse", typeof(Action<TextWriter, object>), Expression.MakeMemberAccess(optionsParameter, typeof(HelperOptions).GetProperty("Inverse"))),
Languages\angular\Angular.cs (4)
107Action<TextWriter, object> template, 196Action<TextWriter, object> template, 282public static void Serialize(TextWriter output, object context, Action<TextWriter, object> template, TypeReference reference, params object[] args) 312public static void Deserialize(TextWriter output, object context, Action<TextWriter, object> template, TypeReference reference, params object[] args)
Languages\csharp\CSharp.cs (2)
165public void NullCheck(TextWriter output, object context, Action<TextWriter, object> template, TypeReference reference, bool required) 181public void NotNullCheck(TextWriter output, object context, Action<TextWriter, object> template, TypeReference reference, bool required)
Languages\Language.cs (1)
39private static Action<TextWriter, object> LoadTemplateFile(IHandlebars hb, string path)
Microsoft.DotNet.XUnitAssert.Tests (2)
AsyncCollectionAssertsTests.cs (1)
23 Assert.Throws<ArgumentNullException>("action", () => Assert.All(new object[0].ToAsyncEnumerable(), (Action<object, int>)null!));
CollectionAssertsTests.cs (1)
21 Assert.Throws<ArgumentNullException>("action", () => Assert.All(new object[0], (Action<object, int>)null!));
Microsoft.Extensions.AI.OpenAI (2)
src\Shared\ServerSentEvents\SseFormatter.cs (2)
54public static Task WriteAsync<T>(IAsyncEnumerable<SseItem<T>> source, Stream destination, Action<SseItem<T>, IBufferWriter<byte>> itemFormatter, CancellationToken cancellationToken = default) 74private static async Task WriteAsyncCore<T>(IAsyncEnumerable<SseItem<T>> source, Stream destination, Action<SseItem<T>, IBufferWriter<byte>> itemFormatter, CancellationToken cancellationToken)
Microsoft.Extensions.FileSystemGlobbing (7)
Internal\IPatternContext.cs (1)
15void Declare(Action<IPathSegment, bool> onDeclare);
Internal\PatternContexts\CompositePatternContext.cs (1)
11public abstract void Declare(Action<IPathSegment, bool> onDeclare);
Internal\PatternContexts\IncludesFirstCompositePatternContext.cs (1)
20public override void Declare(Action<IPathSegment, bool> onDeclare)
Internal\PatternContexts\PatternContext.cs (1)
15public virtual void Declare(Action<IPathSegment, bool> declare) { }
Internal\PatternContexts\PatternContextLinearInclude.cs (1)
16public override void Declare(Action<IPathSegment, bool> onDeclare)
Internal\PatternContexts\PatternContextRaggedInclude.cs (1)
17public override void Declare(Action<IPathSegment, bool> onDeclare)
Internal\PatternContexts\PreserveOrderCompositePatternContext.cs (1)
16public override void Declare(Action<IPathSegment, bool> onDeclare)
Microsoft.Extensions.Hosting (22)
HostApplicationBuilder.cs (7)
261private readonly List<Action<HostBuilderContext, IConfigurationBuilder>> _configureAppConfigActions = new(); 263private readonly List<Action<HostBuilderContext, IServiceCollection>> _configureServicesActions = new(); 308foreach (Action<HostBuilderContext, IConfigurationBuilder> configureAppAction in _configureAppConfigActions) 312foreach (Action<HostBuilderContext, IServiceCollection> configureServicesAction in _configureServicesActions) 354public IHostBuilder ConfigureAppConfiguration(Action<HostBuilderContext, IConfigurationBuilder> configureDelegate) 362public IHostBuilder ConfigureServices(Action<HostBuilderContext, IServiceCollection> configureDelegate) 387public IHostBuilder ConfigureContainer<TContainerBuilder>(Action<HostBuilderContext, TContainerBuilder> configureDelegate)
HostBuilder.cs (9)
29private readonly List<Action<HostBuilderContext, IConfigurationBuilder>> _configureAppConfigActions = new List<Action<HostBuilderContext, IConfigurationBuilder>>(); 30private readonly List<Action<HostBuilderContext, IServiceCollection>> _configureServicesActions = new List<Action<HostBuilderContext, IServiceCollection>>(); 79public IHostBuilder ConfigureAppConfiguration(Action<HostBuilderContext, IConfigurationBuilder> configureDelegate) 93public IHostBuilder ConfigureServices(Action<HostBuilderContext, IServiceCollection> configureDelegate) 139public IHostBuilder ConfigureContainer<TContainerBuilder>(Action<HostBuilderContext, TContainerBuilder> configureDelegate) 283foreach (Action<HostBuilderContext, IConfigurationBuilder> buildAction in _configureAppConfigActions) 346foreach (Action<HostBuilderContext, IServiceCollection> configureServicesAction in _configureServicesActions)
HostingHostBuilderExtensions.cs (4)
82public static IHostBuilder UseDefaultServiceProvider(this IHostBuilder hostBuilder, Action<HostBuilderContext, ServiceProviderOptions> configure) 98public static IHostBuilder ConfigureLogging(this IHostBuilder hostBuilder, Action<HostBuilderContext, ILoggingBuilder> configureLogging) 120public static IHostBuilder ConfigureHostOptions(this IHostBuilder hostBuilder, Action<HostBuilderContext, HostOptions> configureOptions) 427public static IHostBuilder ConfigureMetrics(this IHostBuilder hostBuilder, Action<HostBuilderContext, IMetricsBuilder> configureMetrics)
Internal\ConfigureContainerAdapter.cs (2)
10private readonly Action<HostBuilderContext, TContainerBuilder> _action; 12public ConfigureContainerAdapter(Action<HostBuilderContext, TContainerBuilder> action)
Microsoft.Extensions.Hosting.Abstractions (4)
IHost.cs (1)
16/// Gets the services configured for the program (for example, using <see cref="IHostBuilder.ConfigureServices(Action{HostBuilderContext, Microsoft.Extensions.DependencyInjection.IServiceCollection})" />).
IHostBuilder.cs (3)
38IHostBuilder ConfigureAppConfiguration(Action<HostBuilderContext, IConfigurationBuilder> configureDelegate); 46IHostBuilder ConfigureServices(Action<HostBuilderContext, IServiceCollection> configureDelegate); 71IHostBuilder ConfigureContainer<TContainerBuilder>(Action<HostBuilderContext, TContainerBuilder> configureDelegate);
Microsoft.Extensions.Hosting.Systemd (1)
SystemdHostBuilderExtensions.cs (1)
65/// <see cref="IHostBuilder.ConfigureServices(System.Action{HostBuilderContext, IServiceCollection})"/> callback.
Microsoft.Extensions.Hosting.Testing (3)
FakeHostBuilder.cs (3)
67public IHostBuilder ConfigureAppConfiguration(Action<HostBuilderContext, IConfigurationBuilder> configureDelegate) 72public IHostBuilder ConfigureServices(Action<HostBuilderContext, IServiceCollection> configureDelegate) 89public IHostBuilder ConfigureContainer<TContainerBuilder>(Action<HostBuilderContext, TContainerBuilder> configureDelegate) => _builder.ConfigureContainer(configureDelegate);
Microsoft.Extensions.Hosting.Testing.Tests (5)
FakeHostBuilderTests.cs (2)
75var configurationDelegate = (HostBuilderContext _, IConfigurationBuilder _) => { }; 101var configurationDelegate = (HostBuilderContext _, object _) => { };
HostingFakesExtensionsTests.cs (3)
118.Setup(x => x.ConfigureAppConfiguration(It.IsAny<Action<HostBuilderContext, IConfigurationBuilder>>())) 337.Setup(x => x.ConfigureAppConfiguration(It.IsAny<Action<HostBuilderContext, IConfigurationBuilder>>())) 339.Callback<Action<HostBuilderContext?, IConfigurationBuilder>>(configure => configure(null, appConfigBuilder));
Microsoft.Extensions.Hosting.WindowsServices (2)
WindowsServiceLifetimeHostBuilderExtensions.cs (2)
72/// <see cref="IHostBuilder.ConfigureServices(Action{HostBuilderContext, IServiceCollection})"/> callback. 91/// <see cref="IHostBuilder.ConfigureServices(Action{HostBuilderContext, IServiceCollection})"/> callback.
Microsoft.Extensions.Http (10)
DependencyInjection\HttpClientBuilderExtensions.cs (4)
48public static IHttpClientBuilder ConfigureHttpClient(this IHttpClientBuilder builder, Action<IServiceProvider, HttpClient> configureClient) 238public static IHttpClientBuilder ConfigurePrimaryHttpMessageHandler(this IHttpClientBuilder builder, Action<HttpMessageHandler, IServiceProvider> configureHandler) 286public static IHttpClientBuilder UseSocketsHttpHandler(this IHttpClientBuilder builder, Action<SocketsHttpHandler, IServiceProvider>? configureHandler = null) 636public static IHttpClientBuilder ConfigureAdditionalHttpMessageHandlers(this IHttpClientBuilder builder, Action<IList<DelegatingHandler>, IServiceProvider> configureAdditionalHandlers)
DependencyInjection\HttpClientFactoryServiceCollectionExtensions.cs (5)
165public static IHttpClientBuilder AddHttpClient(this IServiceCollection services, string name, Action<IServiceProvider, HttpClient> configureClient) 401this IServiceCollection services, Action<IServiceProvider, HttpClient> configureClient) 488this IServiceCollection services, Action<IServiceProvider, HttpClient> configureClient) 573this IServiceCollection services, string name, Action<IServiceProvider, HttpClient> configureClient) 666this IServiceCollection services, string name, Action<IServiceProvider, HttpClient> configureClient)
DependencyInjection\SocketsHttpHandlerBuilderExtensions.cs (1)
28public static ISocketsHttpHandlerBuilder Configure(this ISocketsHttpHandlerBuilder builder, Action<SocketsHttpHandler, IServiceProvider> configure)
Microsoft.Extensions.Http.Diagnostics.PerformanceTests (1)
StaticOptionsMonitor.cs (1)
21public IDisposable OnChange(Action<T, string> listener)
Microsoft.Extensions.Http.Polly (1)
DependencyInjection\PollyServiceCollectionExtensions.cs (1)
89public static IServiceCollection AddPolicyRegistry(this IServiceCollection services, Action<IServiceProvider, IPolicyRegistry<string>> configureRegistry)
Microsoft.Extensions.Http.Resilience (6)
Hedging\StandardHedgingHandlerBuilderExtensions.cs (1)
63public static IStandardHedgingHandlerBuilder Configure(this IStandardHedgingHandlerBuilder builder, Action<HttpStandardHedgingResilienceOptions, IServiceProvider> configure)
Resilience\HttpStandardResiliencePipelineBuilderExtensions.cs (1)
66public static IHttpStandardResiliencePipelineBuilder Configure(this IHttpStandardResiliencePipelineBuilder builder, Action<HttpStandardResilienceOptions, IServiceProvider> configure)
Resilience\ResilienceHttpClientBuilderExtensions.Resilience.cs (2)
61Action<ResiliencePipelineBuilder<HttpResponseMessage>, ResilienceHandlerContext> configure) 137Action<ResiliencePipelineBuilder<HttpResponseMessage>, ResilienceHandlerContext> configure)
Routing\RoutingStrategyBuilderExtensions.cs (2)
61public static IRoutingStrategyBuilder ConfigureOrderedGroups(this IRoutingStrategyBuilder builder, Action<OrderedGroupsRoutingOptions, IServiceProvider> configure) 107public static IRoutingStrategyBuilder ConfigureWeightedGroups(this IRoutingStrategyBuilder builder, Action<WeightedGroupsRoutingOptions, IServiceProvider> configure)
Microsoft.Extensions.Http.Resilience.Tests (2)
Resilience\HttpClientBuilderExtensionsTests.Resilience.cs (1)
37Assert.Throws<ArgumentNullException>(() => builder.AddResilienceHandler("dummy", (Action<ResiliencePipelineBuilder<HttpResponseMessage>, ResilienceHandlerContext>)null!));
Routing\RoutingStrategyTest.cs (1)
112Action<IRoutingStrategyBuilder, IConfiguration> configure,
Microsoft.Extensions.Logging (3)
LoggerFactoryScopeProvider.cs (1)
23public void ForEachScope<TState>(Action<object?, TState> callback, TState state)
src\libraries\Common\src\Extensions\Logging\NullExternalScopeProvider.cs (1)
23void IExternalScopeProvider.ForEachScope<TState>(Action<object?, TState> callback, TState state)
StaticFilterOptionsMonitor.cs (1)
16public IDisposable? OnChange(Action<LoggerFilterOptions, string> listener) => null;
Microsoft.Extensions.Logging.Abstractions (5)
IExternalScopeProvider.cs (1)
20void ForEachScope<TState>(Action<object?, TState> callback, TState state);
LoggerExternalScopeProvider.cs (1)
23public void ForEachScope<TState>(Action<object?, TState> callback, TState state)
LoggerMessage.cs (2)
130public static Action<ILogger, Exception?> Define(LogLevel logLevel, EventId eventId, string formatString) 141public static Action<ILogger, Exception?> Define(LogLevel logLevel, EventId eventId, string formatString, LogDefineOptions? options)
src\libraries\Common\src\Extensions\Logging\NullExternalScopeProvider.cs (1)
23void IExternalScopeProvider.ForEachScope<TState>(Action<object?, TState> callback, TState state)
Microsoft.Extensions.Logging.Console (2)
FormatterOptionsMonitor.cs (1)
23public IDisposable? OnChange(Action<TOptions, string> listener)
src\libraries\Common\src\Extensions\Logging\NullExternalScopeProvider.cs (1)
23void IExternalScopeProvider.ForEachScope<TState>(Action<object?, TState> callback, TState state)
Microsoft.Extensions.Logging.Debug (1)
src\libraries\Common\src\Extensions\Logging\NullExternalScopeProvider.cs (1)
23void IExternalScopeProvider.ForEachScope<TState>(Action<object?, TState> callback, TState state)
Microsoft.Extensions.Logging.EventLog (1)
src\libraries\Common\src\Extensions\Logging\NullExternalScopeProvider.cs (1)
23void IExternalScopeProvider.ForEachScope<TState>(Action<object?, TState> callback, TState state)
Microsoft.Extensions.Logging.EventSource (1)
src\libraries\Common\src\Extensions\Logging\NullExternalScopeProvider.cs (1)
23void IExternalScopeProvider.ForEachScope<TState>(Action<object?, TState> callback, TState state)
Microsoft.Extensions.Options (11)
ConfigureNamedOptions.cs (2)
73public ConfigureNamedOptions(string? name, TDep dependency, Action<TOptions, TDep>? action) 88public Action<TOptions, TDep>? Action { get; }
IOptionsMonitor.cs (1)
32IDisposable? OnChange(Action<TOptions, string?> listener);
OptionsBuilder.cs (2)
65public virtual OptionsBuilder<TOptions> Configure<TDep>(Action<TOptions, TDep> configureOptions) 214public virtual OptionsBuilder<TOptions> PostConfigure<TDep>(Action<TOptions, TDep> configureOptions)
OptionsMonitor.cs (4)
23internal event Action<TOptions, string>? _onChange; 109public IDisposable OnChange(Action<TOptions, string> listener) 132private readonly Action<TOptions, string> _listener; 135public ChangeTrackerDisposable(OptionsMonitor<TOptions> monitor, Action<TOptions, string> listener)
PostConfigureOptions.cs (2)
67public PostConfigureOptions(string? name, TDep dependency, Action<TOptions, TDep>? action) 82public Action<TOptions, TDep>? Action { get; }
Microsoft.Extensions.Options.Contextual (5)
ContextualOptionsServiceCollectionExtensions.cs (3)
77public static IServiceCollection Configure<TOptions>(this IServiceCollection services, Action<IOptionsContext, TOptions> configure) 91public static IServiceCollection Configure<TOptions>(this IServiceCollection services, string? name, Action<IOptionsContext, TOptions> configure) 123public static IServiceCollection ConfigureAll<TOptions>(this IServiceCollection services, Action<IOptionsContext, TOptions> configure)
Internal\ConfigureContextualOptions.cs (2)
24public ConfigureContextualOptions(Action<IOptionsContext, TOptions> configureOptions, IOptionsContext context) 33public Action<IOptionsContext, TOptions> ConfigureOptions { get; }
Microsoft.Extensions.Options.Contextual.Tests (2)
ContextualOptionsServiceCollectionExtensionsTests.cs (2)
44Action<IOptionsContext, string> configureOptions = (_, _) => { }; 66Action<IOptionsContext, string> configureOptions = (_, _) => { };
Microsoft.Extensions.Telemetry (1)
Logging\Import\LoggerFactoryScopeProvider.cs (1)
42public void ForEachScope<TState>(Action<object?, TState> callback, TState state)
Microsoft.Extensions.Telemetry.Tests (2)
Logging\ExtendedLoggerTests.cs (1)
1223public IDisposable? OnChange(Action<T, string> listener) => null;
Logging\SerialExtendedLoggerTests.cs (1)
96public IDisposable? OnChange(Action<T, string> listener) => null;
Microsoft.Gen.Logging (2)
Model\LoggingMethodParameterExtensions.cs (2)
13Action<IEnumerable<LoggingProperty>, LoggingProperty> callback) 36Action<IEnumerable<LoggingProperty>, LoggingProperty> callback)
Microsoft.Interop.SourceGeneration (7)
ManualTypeMarshallingHelper.cs (7)
107Action<INamedTypeSymbol, INamedTypeSymbol> onArityMismatch, 128Action<INamedTypeSymbol, INamedTypeSymbol> onArityMismatch, 138Action<INamedTypeSymbol, INamedTypeSymbol> onArityMismatch, 151Action<INamedTypeSymbol, INamedTypeSymbol> onArityMismatch, 241public static bool TryResolveEntryPointType(INamedTypeSymbol managedType, ITypeSymbol typeInAttribute, bool isLinearCollectionMarshalling, Action<INamedTypeSymbol, INamedTypeSymbol> onArityMismatch, [NotNullWhen(true)] out ITypeSymbol? entryPoint) 283public static bool TryResolveManagedType(INamedTypeSymbol entryPointType, ITypeSymbol typeInAttribute, bool isLinearCollectionMarshalling, Action<INamedTypeSymbol, INamedTypeSymbol> onArityMismatch, [NotNullWhen(true)] out ITypeSymbol? managed) 326public static bool TryResolveMarshallerType(INamedTypeSymbol entryPointType, ITypeSymbol typeInAttribute, Action<INamedTypeSymbol, INamedTypeSymbol> onArityMismatch, [NotNullWhen(true)] out ITypeSymbol? marshallerType)
Microsoft.Maui (33)
CommandMapper.cs (2)
72 void Add(string key, Action<TViewHandler, TVirtualView> action); 101 public void Add(string key, Action<TViewHandler, TVirtualView> action) =>
PropertyMapper.cs (22)
20 protected readonly Dictionary<string, Action<IElementHandler, IElement>> _mapper = new(StringComparer.Ordinal); 24 List<Action<IElementHandler, IElement>>? _updatePropertiesMappers; 25 Dictionary<string, Action<IElementHandler, IElement>?>? _cachedMappers; 28 List<Action<IElementHandler, IElement>> UpdatePropertiesMappers => _updatePropertiesMappers ?? SnapshotMappers().UpdatePropertiesMappers; 29 Dictionary<string, Action<IElementHandler, IElement>?> CachedMappers => _cachedMappers ?? SnapshotMappers().CachedMappers; 40 protected virtual void SetPropertyCore(string key, Action<IElementHandler, IElement> action) 60 if (cachedMappers.TryGetValue(key, out var action)) 73 var mapper = GetProperty(key); 85 public virtual Action<IElementHandler, IElement>? GetProperty(string key) 87 if (_mapper.TryGetValue(key, out var action)) 97 var returnValue = ch.GetProperty(key); 125 foreach (var mapper in UpdatePropertiesMappers) 177 private (List<string> UpdatePropertiesKeys, List<Action<IElementHandler, IElement>> UpdatePropertiesMappers, Dictionary<string, Action<IElementHandler, IElement>?> CachedMappers) SnapshotMappers() 180 var updatePropertiesMappers = new List<Action<IElementHandler, IElement>>(updatePropertiesKeys.Count); 186 var cachedMappers = new Dictionary<string, Action<IElementHandler, IElement>?>(cacheSize); 190 var mapper = GetProperty(key)!; 205 Action<IElementHandler, IElement>? GetProperty(string key); 218 void Add(string key, Action<TViewHandler, TVirtualView> action); 234 public Action<TViewHandler, TVirtualView> this[string key] 238 var action = GetProperty(key) ?? throw new IndexOutOfRangeException($"Unable to find mapping for '{nameof(key)}'."); 244 public void Add(string key, Action<TViewHandler, TVirtualView> action) =>
PropertyMapperExtensions.cs (9)
16 string key, Action<TViewHandler, TVirtualView, Action<IElementHandler, IElement>?> method) 19 var previousMethod = propertyMapper.GetProperty(key); 38 string key, Action<TViewHandler, TVirtualView, Action<IElementHandler, IElement>?> method) 41 var previousMethod = propertyMapper.GetProperty(key); 63 string key, Action<TViewHandler, TVirtualView> method) 78 string key, Action<TViewHandler, TVirtualView> method) 97 string key, Action<TViewHandler, TVirtualView> method) 118 string key, Action<TViewHandler, TVirtualView> method) 137 string key, Action<TViewHandler, TVirtualView> method)
Microsoft.Maui.Controls (30)
Animation.cs (1)
71 public void Commit(IAnimatable owner, string name, uint rate = 16, uint length = 250, Easing easing = null, Action<double, bool> finished = null, Func<bool> repeat = null)
AnimationExtensions.cs (7)
136 public static void Animate(this IAnimatable self, string name, Animation animation, uint rate = 16, uint length = 250, Easing easing = null, Action<double, bool> finished = null, 156 Action<double, bool> finished = null, Func<bool> repeat = null) 162 public static void Animate(this IAnimatable self, string name, Action<double> callback, uint rate = 16, uint length = 250, Easing easing = null, Action<double, bool> finished = null, 172 Action<T, bool> finished = null, Func<bool> repeat = null, IAnimationManager animationManager = null) 256 uint rate, uint length, Easing easing, Action<T, bool> finished, Func<bool> repeat) 263 Action<double, bool> final = null; 389 public Action<double, bool> Finished;
BindableObjectExtensions.cs (1)
35 internal static void PropagateBindingContext<T>(this BindableObject self, IEnumerable<T> children, Action<BindableObject, object> setChildBindingContext)
Element\Element.cs (5)
61 List<Action<object, ResourcesChangedEventArgs>> _changeHandlers; 372 void IElementDefinition.AddResourcesChangedListener(Action<object, ResourcesChangedEventArgs> onchanged) 374 _changeHandlers ??= new List<Action<object, ResourcesChangedEventArgs>>(2); 443 void IElementDefinition.RemoveResourcesChangedListener(Action<object, ResourcesChangedEventArgs> onchanged) 753 foreach (Action<object, ResourcesChangedEventArgs> handler in _changeHandlers.ToList())
ElementTemplate.cs (5)
12 List<Action<object, ResourcesChangedEventArgs>> _changeHandlers; 40 void IElementDefinition.AddResourcesChangedListener(Action<object, ResourcesChangedEventArgs> onchanged) 42 _changeHandlers = _changeHandlers ?? new List<Action<object, ResourcesChangedEventArgs>>(1); 66 void IElementDefinition.RemoveResourcesChangedListener(Action<object, ResourcesChangedEventArgs> onchanged) 104 foreach (Action<object, ResourcesChangedEventArgs> handler in _changeHandlers)
IElementDefinition.cs (2)
14 void AddResourcesChangedListener(Action<object, ResourcesChangedEventArgs> onchanged); 17 void RemoveResourcesChangedListener(Action<object, ResourcesChangedEventArgs> onchanged);
Internals\NotifyCollectionChangedEventArgsExtensions.cs (1)
25 public static NotifyCollectionChangedAction Apply(this NotifyCollectionChangedEventArgs self, Action<object, int, bool> insert, Action<object, int> removeAt, Action reset)
MessagingCenter.cs (3)
15 void Subscribe<TSender, TArgs>(object subscriber, string message, Action<TSender, TArgs> callback, TSender source = null) where TSender : class; 134 public static void Subscribe<TSender, TArgs>(object subscriber, string message, Action<TSender, TArgs> callback, TSender source = null) where TSender : class 139 void IMessagingCenter.Subscribe<TSender, TArgs>(object subscriber, string message, Action<TSender, TArgs> callback, TSender source)
StyleSheets\Selector.cs (1)
17 Action<Operator, Selector> setCurrentSelector = (op, sel) => SetCurrentSelector(ref root, ref workingRoot, ref workingRootParent, op, sel);
TypedBinding.cs (3)
97 Action<TSource, TProperty> setter = null, 123 readonly Action<TSource, TProperty> _setter; 126 public TypedBinding(Func<TSource, (TProperty value, bool success)> getter, Action<TSource, TProperty> setter, Tuple<Func<TSource, object>, string>[] handlers)
ViewExtensions.cs (1)
39 Action<VisualElement, double> updateAction, uint length = 250, Easing? easing = null)
Microsoft.Maui.Controls.SourceGen (2)
src\Controls\src\Xaml\XamlNodeVisitor.cs (2)
30 readonly Action<INode, INode> action; 32 public XamlNodeVisitor(Action<INode, INode> action, TreeVisitingMode visitingMode = TreeVisitingMode.TopDown, bool stopOnDataTemplate = false, bool visitNodeOnDataTemplate = true)
Microsoft.Maui.Controls.Xaml (2)
XamlNodeVisitor.cs (2)
30 readonly Action<INode, INode> action; 32 public XamlNodeVisitor(Action<INode, INode> action, TreeVisitingMode visitingMode = TreeVisitingMode.TopDown, bool stopOnDataTemplate = false, bool visitNodeOnDataTemplate = true)
Microsoft.ML.Core (20)
Environment\ConsoleEnvironment.cs (1)
332Action<IMessageSource, ChannelMessage> dispatch)
Environment\HostEnvironmentBase.cs (13)
161protected readonly Action<IMessageSource, TMessage> Dispatch; 168Action<IMessageSource, TMessage> dispatch) 218Action<IMessageSource, ChannelMessage> dispatch) 271Action<IMessageSource, TMessage> dispatch) : 297private volatile Action<IMessageSource, TMessage> _listenerAction; 302private readonly Action<IMessageSource, TMessage> _dispatch; 309public Action<IMessageSource, TMessage> Dispatch { get { return _dispatch; } } 316public void AddListener(Action<IMessageSource, TMessage> listenerFunc) 322public void RemoveListener(Action<IMessageSource, TMessage> listenerFunc) 452Action<IMessageSource, TMessage> listenerAction, IMessageSource channel, TMessage message) 459protected Action<IMessageSource, TMessage> GetDispatchDelegate<TMessage>() 497public void AddListener<TMessage>(Action<IMessageSource, TMessage> listenerFunc) 504public void RemoveListener<TMessage>(Action<IMessageSource, TMessage> listenerFunc)
Utilities\Contracts.cs (4)
64private static volatile Action<string, IExceptionContext> _handler; 237public static Action<string, IExceptionContext> SetAssertHandler(Action<string, IExceptionContext> handler) 778var handler = _handler;
Utilities\Utils.cs (1)
1222public static void MarshalActionInvoke<TArg1, TArg2>(Action<TArg1, TArg2> act, Type genArg, TArg1 arg1, TArg2 arg2)
Utilities\VBufferUtils.cs (1)
83public static void ForEachDefined<T>(in VBuffer<T> a, Action<int, T> visitor)
Microsoft.ML.Core.Tests (1)
UnitTests\TestCustomTypeRegister.cs (1)
169public override Action<AlienHero, SuperAlienHero> GetMapping()
Microsoft.ML.CpuMath (4)
src\Microsoft.ML.Core\Utilities\Contracts.cs (4)
64private static volatile Action<string, IExceptionContext> _handler; 237public static Action<string, IExceptionContext> SetAssertHandler(Action<string, IExceptionContext> handler) 778var handler = _handler;
Microsoft.ML.Data (19)
DataDebuggerPreview.cs (5)
19private static readonly FuncInstanceMethodInfo1<DataDebuggerPreview, DataViewRow, int, Action<RowInfo, List<object>>> _makeSetterMethodInfo 20= FuncInstanceMethodInfo1<DataDebuggerPreview, DataViewRow, int, Action<RowInfo, List<object>>>.Create(target => target.MakeSetter<int>); 46var setters = new Action<RowInfo, List<object>>[n]; 68private Action<RowInfo, List<object>> MakeSetter<T>(DataViewRow row, int col) 72Action<RowInfo, List<object>> result = (rowInfo, list) =>
DataLoadSave\Binary\BinaryLoader.cs (1)
2230Action<string, long> report =
DataLoadSave\Text\TextSaver.cs (8)
84public abstract void WriteData(Action<StringBuilder, int> appendItem, out int length); 86public abstract void WriteHeader(Action<StringBuilder, int> appendItem, out int length); 176public override void WriteData(Action<StringBuilder, int> appendItem, out int length) 200public override void WriteHeader(Action<StringBuilder, int> appendItem, out int length) 234public override void WriteData(Action<StringBuilder, int> appendItem, out int length) 242public override void WriteHeader(Action<StringBuilder, int> appendItem, out int length) 581Action<StringBuilder, int> append = (sb, index) => AppendItem(sb, index, _pipes[_col].Default); 582Action<StringBuilder, int> appendHeader = (sb, index) => AppendItem(sb, index, "");
DataLoadSave\Transpose\TransposeSaver.cs (1)
131Action<string, IDataView> viewAction =
Prediction\CalibratorCatalog.cs (1)
87Action<SchemaShape.Column, string> checkColumnValid = (SchemaShape.Column column, string columnRole) =>
Utilities\LocalEnvironment.cs (3)
21Action<IMessageSource, ChannelMessage> dispatch) 57public void AddListener(Action<IMessageSource, ChannelMessage> listener) 63public void RemoveListener(Action<IMessageSource, ChannelMessage> listener)
Microsoft.ML.FastTree (1)
TreeEnsemble\InternalRegressionTree.cs (1)
436private void CheckValid(Action<bool, string> checker)
Microsoft.ML.IntegrationTests (3)
Datasets\Iris.cs (1)
43Action<Iris, IrisWithGroup> generateGroupId = (input, output) =>
DataTransformation.cs (2)
50Action<Iris, IrisWithOneExtraColumn> generateGroupId = (input, output) => 95Action<Iris, IrisWithTwoExtraColumns> generateGroupId = (input, output) =>
Microsoft.ML.OnnxTransformerTest (2)
OnnxTransformTests.cs (2)
837/// Use <see cref="CustomMappingCatalog.CustomMapping{TSrc, TDst}(TransformsCatalog, Action{TSrc, TDst}, string, SchemaDefinition, SchemaDefinition)"/> 851Action<OnnxMapInput, OnnxMapOutput> action = (input, output) =>
Microsoft.ML.Predictor.Tests (2)
CmdLine\CmdLine.cs (2)
86Action<IndentedTextWriter, string> action = null; 341Action<IndentedTextWriter, string> action)
Microsoft.ML.Samples (7)
Dynamic\TensorFlow\TextClassification.cs (1)
90Action<IMDBSentiment, IntermediateFeatures> ResizeFeaturesAction =
Dynamic\TextTransform.cs (1)
76Action<string, IEnumerable<VBuffer<float>>> printHelper = (columnName,
Dynamic\Transforms\CustomMapping.cs (1)
31Action<InputData, CustomMappingOutput> mapping =
Dynamic\Transforms\CustomMappingSaveAndLoad.cs (1)
91public override Action<InputData, CustomMappingOutput> GetMapping()
Dynamic\Transforms\CustomMappingWithInMemoryCustomType.cs (1)
216public static Action<AlienHero, SuperAlienHero> GetMapping()
Dynamic\Transforms\Projection\VectorWhiten.cs (1)
36Action<string, IEnumerable<VBuffer<float>>> printHelper = (colName,
Dynamic\Transforms\Projection\VectorWhitenWithOptions.cs (1)
35Action<string, IEnumerable<VBuffer<float>>> printHelper = (colName,
Microsoft.ML.Samples.GPU (1)
docs\samples\Microsoft.ML.Samples\Dynamic\TensorFlow\TextClassification.cs (1)
90Action<IMDBSentiment, IntermediateFeatures> ResizeFeaturesAction =
Microsoft.ML.StandardTrainers (2)
Standard\SdcaBinary.cs (2)
2070Action<int, IProgressChannel> checkConvergence = (e, pch) => 2108var trainingTasks = new Action<Random, IProgressChannel>[_options.NumberOfIterations];
Microsoft.ML.TestFramework (2)
GlobalBase.cs (2)
25var prev = Contracts.SetAssertHandler(AssertHandler); 64var prev = Contracts.SetAssertHandler(null);
Microsoft.ML.Tests (7)
Scenarios\Api\CookbookSamples\CookbookSamplesDynamicApi.cs (3)
731public override Action<InputRow, OutputRow> GetMapping() 768Action<InputRow, OutputRow> mapping = (input, output) => output.Label = input.Income > 50000; 777Action<InputRow, OutputRow> mapping = (input, output) => output.Label = input.Income > 50000;
Scenarios\Api\Estimators\Extensibility.cs (1)
33Action<IrisData, IrisData> action = (i, j) =>
TrainerEstimators\TreeEnsembleFeaturizerTest.cs (1)
794Action<RowWithKey, RowWithFloat> actionConvertKeyToFloat = (RowWithKey rowWithKey, RowWithFloat rowWithFloat) =>
Transformers\CustomMappingTests.cs (2)
43public override Action<MyInput, MyOutput> GetMapping() 100Action<MyInput, MyOutput> mapping = (input, output) => output.Together = input.Float1.ToString();
Microsoft.ML.Transforms (12)
CustomMappingCatalog.cs (1)
44public static CustomMappingEstimator<TSrc, TDst> CustomMapping<TSrc, TDst>(this TransformsCatalog catalog, Action<TSrc, TDst> mapAction, string contractName,
CustomMappingFactory.cs (2)
38public abstract Action<TSrc, TDst> GetMapping(); 42Action<TSrc, TDst> mapAction = GetMapping();
CustomMappingTransformer.cs (4)
23private readonly Action<TSrc, TDst> _mapAction; 44internal CustomMappingTransformer(IHostEnvironment env, Action<TSrc, TDst> mapAction, string contractName, 229/// <seealso cref="CustomMappingCatalog.CustomMapping{TSrc, TDst}(TransformsCatalog, Action{TSrc, TDst}, string, SchemaDefinition, SchemaDefinition)"/> 242internal CustomMappingEstimator(IHostEnvironment env, Action<TSrc, TDst> mapAction, string contractName,
Expression\LambdaParser.cs (2)
107Action<string, TokKind> p = _kwt.AddPunctuator; 142Action<string, TokKind> w = _kwt.AddKeyWord;
Expression\MethodGenerator.cs (3)
70private Action<LocalBuilder, bool> _dispose; 75internal Temporary(Action<LocalBuilder, bool> dispose, LocalBuilder localBuilder, bool isRef) 140private Action<LocalBuilder, bool> _tempDisposer;
Microsoft.ML.Vision (1)
ImageClassificationTrainer.cs (1)
1069IntPtr featureBufferPtr, IntPtr labelBufferPtr, Action<Tensor[], ImageClassificationMetrics> metricsAggregator)
Microsoft.VisualStudio.LanguageServices (2)
Options\VisualStudioSettingsOptionPersister.cs (2)
27private readonly Action<OptionKey2, object?> _refreshOption; 40public VisualStudioSettingsOptionPersister(Action<OptionKey2, object?> refreshOption, ImmutableDictionary<string, Lazy<IVisualStudioStorageReadFallback, OptionNameMetadata>> readFallbacks, ISettingsManager settingsManager)
Microsoft.VisualStudio.LanguageServices.CSharp (1)
CodeModel\CSharpCodeModelService.CodeModelEventCollector.cs (1)
970private static void AddEventToEventQueueForAttributes(AttributeSyntax attribute, SyntaxNode parent, Action<SyntaxNode, SyntaxNode> enqueueAddOrRemoveEvent)
Microsoft.VisualStudio.LanguageServices.Implementation (3)
CodeModel\InternalElements\AbstractCodeElement.cs (1)
88protected void UpdateNode<T>(Action<SyntaxNode, T> updater, T value)
CodeModel\InternalElements\AbstractKeyedCodeElement.cs (1)
77protected void UpdateNodeAndReacquireNodeKey<T>(Action<SyntaxNode, T> updater, T value, bool trackKinds = true)
CodeModel\InternalElements\CodeParameter.cs (1)
50private void UpdateNodeAndReacquireParentNodeKey<T>(Action<SyntaxNode, T> parameterUpdater, T value)
mscorlib (1)
src\libraries\shims\mscorlib\ref\mscorlib.cs (1)
31[assembly: System.Runtime.CompilerServices.TypeForwardedTo(typeof(System.Action<,>))]
netstandard (1)
netstandard.cs (1)
26[assembly: System.Runtime.CompilerServices.TypeForwardedTo(typeof(System.Action<,>))]
PresentationCore (5)
System\Windows\Input\TouchDevice.cs (3)
448Action<DependencyObject, bool> originChangedAction = capture ? null : RaiseTouchEnterOrLeaveAction; 916private Action<DependencyObject, bool> RaiseTouchEnterOrLeaveAction 1299private Action<DependencyObject, bool> _raiseTouchEnterOrLeaveAction;
System\Windows\ReverseInheritProperty.cs (2)
43Action<DependencyObject, bool> originChangedAction) 160Action<DependencyObject, bool> originChangedAction)
PresentationFramework (12)
MS\Internal\WindowsRuntime\Generated\WinRT\Marshalers.cs (10)
375public static readonly Action<object, IntPtr> CopyAbi; 376private static Action<object, IntPtr> BindCopyAbi() 381return Expression.Lambda<Action<object, IntPtr>>( 404public static readonly Action<T, IntPtr> CopyManaged; 405private static Action<T, IntPtr> BindCopyManaged() 410return Expression.Lambda<Action<T, IntPtr>>( 714public static unsafe void CopyManagedArray(T[] array, IntPtr data, Action<T, IntPtr> copyManaged) 1105public static readonly Action<object, IntPtr> CopyAbi; 1108public static readonly Action<T, IntPtr> CopyManaged; 1115public static readonly Action<T[], IntPtr> CopyManagedArray;
System\Windows\Markup\Baml2006\WpfKnownMember.cs (2)
26private Action<object, object> _setDelegate; 112public Action<object, object> SetDelegate
Roslyn.Diagnostics.Analyzers (21)
src\Dependencies\PooledObjects\PooledDelegates.cs (8)
98public static Releaser GetPooledAction<T1, TArg>(Action<T1, TArg> unboundAction, TArg argument, out Action<T1> boundAction) 99=> GetPooledDelegate<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>>(unboundAction, argument, out boundAction); 102/// Gets an <see cref="Action{T1, T2}"/> delegate, which calls <paramref name="unboundAction"/> with the specified 132public static Releaser GetPooledAction<T1, T2, TArg>(Action<T1, T2, TArg> unboundAction, TArg argument, out Action<T1, T2> boundAction) 133=> GetPooledDelegate<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>>(unboundAction, argument, out boundAction); 391: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>> 398: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>> 400protected override Action<T1, T2> Bind()
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Extensions\ObjectWriterExtensions.cs (1)
13public static void WriteArray<T>(this ObjectWriter writer, ImmutableArray<T> values, Action<ObjectWriter, T> write)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\FlowAnalysis\SymbolUsageAnalysis\SymbolUsageAnalysis.BasicBlockAnalysisData.cs (1)
74public void ForEachCurrentWrite<TArg>(ISymbol symbol, Action<IOperation, TArg> action, TArg arg)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Formatting\Engine\AbstractFormatEngine.cs (6)
167var addIndentBlockOperations = _formattingRules.AddIndentBlockOperations; 168var addSuppressOperation = _formattingRules.AddSuppressOperations; 169var addAlignTokensOperations = _formattingRules.AddAlignTokensOperations; 170var addAnchorIndentationOperations = _formattingRules.AddAnchorIndentationOperations; 189private static void AddOperations<T>(SegmentedList<T> operations, List<T> scratch, SyntaxNode node, Action<List<T>, SyntaxNode> addOperations) 203private static void AddOperations<T>(SegmentedList<T> operations, ArrayBuilder<T> scratch, SyntaxNode node, Action<ArrayBuilder<T>, SyntaxNode> addOperations)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\NamingStyles\Serialization\NamingStylePreferencesEditorConfigSerializer.cs (1)
51Action<string, string> entryWriter,
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\ObjectPools\PooledObject.cs (2)
19private readonly Action<ObjectPool<T>, T> _releaser; 22public PooledObject(ObjectPool<T> pool, Func<ObjectPool<T>, T> allocator, Action<ObjectPool<T>, T> releaser) : this()
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Extensions\StringBuilderExtensions.cs (2)
21this StringBuilder builder, string separator, SeparatedSyntaxList<TNode> values, Action<TNode, StringBuilder> append) 37public static StringBuilder AppendJoinedValues<T>(this StringBuilder builder, string separator, ImmutableArray<T> values, Action<T, StringBuilder> append)
Roslyn.Diagnostics.CSharp.Analyzers (1)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\CSharp\Extensions\SyntaxNodeExtensions.cs (1)
762public static void ForEachMember<TArg>(this SyntaxNode? node, Action<MemberDeclarationSyntax, TArg> callback, TArg arg)
Roslyn.VisualStudio.Next.UnitTests (1)
Options\VisualStudioSettingsOptionPersisterTests.cs (1)
38public Action<string, object?>? SetValueImpl;
Shared (2)
ServerSentEvents\SseFormatter.cs (2)
54public static Task WriteAsync<T>(IAsyncEnumerable<SseItem<T>> source, Stream destination, Action<SseItem<T>, IBufferWriter<byte>> itemFormatter, CancellationToken cancellationToken = default) 74private static async Task WriteAsyncCore<T>(IAsyncEnumerable<SseItem<T>> source, Stream destination, Action<SseItem<T>, IBufferWriter<byte>> itemFormatter, CancellationToken cancellationToken)
System.ComponentModel.Composition.Registration (17)
System\ComponentModel\Composition\Registration\PartBuilder.cs (17)
25private Action<ParameterInfo, ImportBuilder> _configureConstructorImports; 28private readonly List<Tuple<Predicate<PropertyInfo>, Action<PropertyInfo, ExportBuilder>, Type>> _propertyExports; 29private readonly List<Tuple<Predicate<PropertyInfo>, Action<PropertyInfo, ImportBuilder>, Type>> _propertyImports; 30private readonly List<Tuple<Predicate<Type>, Action<Type, ExportBuilder>>> _interfaceExports; 40_propertyExports = new List<Tuple<Predicate<PropertyInfo>, Action<PropertyInfo, ExportBuilder>, Type>>(); 41_propertyImports = new List<Tuple<Predicate<PropertyInfo>, Action<PropertyInfo, ImportBuilder>, Type>>(); 42_interfaceExports = new List<Tuple<Predicate<Type>, Action<Type, ExportBuilder>>>(); 80Action<ParameterInfo, ImportBuilder> importConfiguration) 100Action<Type, ExportBuilder> exportConfiguration) 118Action<PropertyInfo, ExportBuilder> exportConfiguration) 136Action<PropertyInfo, ExportBuilder> exportConfiguration) 154Action<PropertyInfo, ImportBuilder> importConfiguration) 171Action<PropertyInfo, ImportBuilder> importConfiguration) 316foreach (Tuple<Predicate<Type>, Action<Type, ExportBuilder>> exportSpecification in _interfaceExports) 386private static void ConfigureConstructorAttributes(ConstructorInfo constructorInfo, ref List<Tuple<object, List<Attribute>>> configuredMembers, Action<ParameterInfo, ImportBuilder> configureConstructorImports) 430foreach (Tuple<Predicate<PropertyInfo>, Action<PropertyInfo, ImportBuilder>, Type> importSpecification in _propertyImports) 470foreach (Tuple<Predicate<PropertyInfo>, Action<PropertyInfo, ExportBuilder>, Type> exportSpecification in _propertyExports)
System.Composition.Convention (22)
System\Composition\Convention\PartConventionBuilder.cs (22)
30private Action<ParameterInfo, ImportConventionBuilder> _configureConstructorImports; 33private readonly List<Tuple<Predicate<PropertyInfo>, Action<PropertyInfo, ExportConventionBuilder>, Type>> _propertyExports; 34private readonly List<Tuple<Predicate<PropertyInfo>, Action<PropertyInfo, ImportConventionBuilder>>> _propertyImports; 35private readonly List<Tuple<Predicate<Type>, Action<Type, ExportConventionBuilder>>> _interfaceExports; 44_propertyExports = new List<Tuple<Predicate<PropertyInfo>, Action<PropertyInfo, ExportConventionBuilder>, Type>>(); 45_propertyImports = new List<Tuple<Predicate<PropertyInfo>, Action<PropertyInfo, ImportConventionBuilder>>>(); 46_interfaceExports = new List<Tuple<Predicate<Type>, Action<Type, ExportConventionBuilder>>>(); 122Action<ParameterInfo, ImportConventionBuilder> importConfiguration) 159Action<Type, ExportConventionBuilder> exportConfiguration) 168Action<Type, ExportConventionBuilder> exportConfiguration) 193Action<PropertyInfo, ExportConventionBuilder> exportConfiguration) 202Action<PropertyInfo, ExportConventionBuilder> exportConfiguration) 229Action<PropertyInfo, ExportConventionBuilder> exportConfiguration) 238Action<PropertyInfo, ExportConventionBuilder> exportConfiguration) 263Action<PropertyInfo, ImportConventionBuilder> importConfiguration) 272Action<PropertyInfo, ImportConventionBuilder> importConfiguration) 299Action<PropertyInfo, ImportConventionBuilder> importConfiguration) 308Action<PropertyInfo, ImportConventionBuilder> importConfiguration) 512foreach (Tuple<Predicate<Type>, Action<Type, ExportConventionBuilder>> exportSpecification in _interfaceExports) 577private static void ConfigureConstructorAttributes(ConstructorInfo constructorInfo, ref List<Tuple<object, List<Attribute>>> configuredMembers, Action<ParameterInfo, ImportConventionBuilder> configureConstructorImports) 676foreach (Tuple<Predicate<PropertyInfo>, Action<PropertyInfo, ImportConventionBuilder>> importSpecification in _propertyImports) 713foreach (Tuple<Predicate<PropertyInfo>, Action<PropertyInfo, ExportConventionBuilder>, Type> exportSpecification in _propertyExports)
System.Core (1)
System.Core.cs (1)
19[assembly: System.Runtime.CompilerServices.TypeForwardedTo(typeof(System.Action<,>))]
System.Diagnostics.DiagnosticSource (20)
System\Diagnostics\ActivitySource.cs (1)
502public void EnumWithAction(Action<T, object> action, object arg)
System\Diagnostics\DiagnosticListener.cs (4)
280internal Action<Activity, object?>? OnActivityImport; 281internal Action<Activity, object?>? OnActivityExport; 431Action<Activity, object?>? onActivityImport, Action<Activity, object?>? onActivityExport)
System\Diagnostics\DiagnosticSourceActivity.cs (2)
144Action<Activity, object?>? onActivityImport = null, Action<Activity, object?>? onActivityExport = null)
System\Diagnostics\Metrics\AggregationManager.cs (10)
38private readonly Action<DateTime, DateTime> _beginCollection; 39private readonly Action<DateTime, DateTime> _endCollection; 40private readonly Action<Instrument, InstrumentState> _beginInstrumentMeasurements; 41private readonly Action<Instrument, InstrumentState> _endInstrumentMeasurements; 42private readonly Action<Instrument, InstrumentState?> _instrumentPublished; 57Action<DateTime, DateTime> beginCollection, 58Action<DateTime, DateTime> endCollection, 59Action<Instrument, InstrumentState> beginInstrumentMeasurements, 60Action<Instrument, InstrumentState> endInstrumentMeasurements, 61Action<Instrument, InstrumentState?> instrumentPublished,
System\Diagnostics\Metrics\MeterListener.cs (3)
50public Action<Instrument, MeterListener>? InstrumentPublished { get; set; } 56public Action<Instrument, object?>? MeasurementsCompleted { get; set; } 255Action<Instrument, object?>? measurementsCompleted = MeasurementsCompleted;
System.Formats.Asn1 (1)
System\Formats\Asn1\AsnWriter.cs (1)
311public void Encode<TState>(TState state, Action<TState, ReadOnlySpan<byte>> encodeCallback)
System.IO.Pipelines (9)
System\IO\Pipelines\Pipe.cs (2)
624internal void OnWriterCompleted(Action<Exception?, object?> callback, object? state) 663internal void OnReaderCompleted(Action<Exception?, object?> callback, object? state)
System\IO\Pipelines\Pipe.DefaultPipeReader.cs (1)
37public override void OnWriterCompleted(Action<Exception?, object?> callback, object? state) => _pipe.OnWriterCompleted(callback, state);
System\IO\Pipelines\Pipe.DefaultPipeWriter.cs (1)
29public override void OnReaderCompleted(Action<Exception?, object?> callback, object? state) => _pipe.OnReaderCompleted(callback, state);
System\IO\Pipelines\PipeCompletion.cs (1)
40public PipeCompletionCallbacks? AddCallback(Action<Exception?, object?> callback, object? state)
System\IO\Pipelines\PipeCompletionCallback.cs (2)
8public readonly Action<Exception?, object?> Callback; 11public PipeCompletionCallback(Action<Exception?, object?> callback, object? state)
System\IO\Pipelines\PipeReader.cs (1)
149public virtual void OnWriterCompleted(Action<Exception?, object?> callback, object? state)
System\IO\Pipelines\PipeWriter.cs (1)
51public virtual void OnReaderCompleted(Action<Exception?, object?> callback, object? state)
System.Linq.Expressions (9)
System\Dynamic\UpdateDelegates.Generated.cs (3)
1479var @this = (CallSite<Action<CallSite, T0>>)site; 1480Action<CallSite, T0>[] applicable; 1481Action<CallSite, T0> rule, originalRule = @this.Target;
System\Linq\Expressions\Compiler\DelegateHelpers.Generated.cs (1)
243return typeof(Action<,>).MakeGenericType(types);
System\Linq\Expressions\Interpreter\CallInstruction.Generated.cs (3)
281private readonly Action<T0, T1> _target; 288_target = (Action<T0, T1>)target.CreateDelegate(typeof(Action<T0, T1>));
System\Linq\Expressions\StackGuard.cs (2)
31public void RunOnEmptyStack<T1, T2>(Action<T1, T2> action, T1 arg1, T2 arg2) => 34var t = ((Action<T1, T2>, T1, T2))s;
System.Net.Http (1)
System\Net\Http\SocketsHttpHandler\ConnectHelper.cs (1)
115public static async ValueTask<QuicConnection> ConnectQuicAsync(HttpRequestMessage request, DnsEndPoint endPoint, TimeSpan idleTimeout, SslClientAuthenticationOptions clientAuthenticationOptions, Action<QuicConnection, QuicStreamCapacityChangedArgs> streamCapacityCallback, CancellationToken cancellationToken)
System.Net.Quic (2)
System\Net\Quic\QuicConnection.cs (1)
191private Action<QuicConnection, QuicStreamCapacityChangedArgs>? _streamCapacityCallback;
System\Net\Quic\QuicConnectionOptions.cs (1)
148public Action<QuicConnection, QuicStreamCapacityChangedArgs>? StreamCapacityCallback { get; set; }
System.Net.ServerSentEvents (2)
System\Net\ServerSentEvents\SseFormatter.cs (2)
51public static Task WriteAsync<T>(IAsyncEnumerable<SseItem<T>> source, Stream destination, Action<SseItem<T>, IBufferWriter<byte>> itemFormatter, CancellationToken cancellationToken = default) 71private static async Task WriteAsyncCore<T>(IAsyncEnumerable<SseItem<T>> source, Stream destination, Action<SseItem<T>, IBufferWriter<byte>> itemFormatter, CancellationToken cancellationToken)
System.Net.Sockets (4)
System\Net\Sockets\SocketAsyncContext.Unix.cs (2)
698public Action<long, SocketError>? Callback { get; set; } 2158public SocketError SendFileAsync(SafeFileHandle fileHandle, long offset, long count, out long bytesSent, Action<long, SocketError> callback, CancellationToken cancellationToken = default)
System\Net\Sockets\SocketPal.Unix.cs (2)
2070private static SocketError SendFileAsync(SafeSocketHandle handle, SafeFileHandle fileHandle, long offset, long count, CancellationToken cancellationToken, Action<long, SocketError> callback) 2082Socket socket, TransmitFileOptions options, SendPacketsElement[] elements, SafeFileHandle[] fileHandles, CancellationToken cancellationToken, Action<long, SocketError> callback)
System.Net.WebClient (1)
System\Net\WebClient.cs (1)
1790private void HandleCompletion<TAsyncCompletedEventArgs, TCompletionDelegate, T>(TaskCompletionSource<T> tcs, TAsyncCompletedEventArgs e, Func<TAsyncCompletedEventArgs, T> getResult, TCompletionDelegate handler, Action<WebClient, TCompletionDelegate> unregisterHandler)
System.Private.CoreLib (25)
src\libraries\System.Private.CoreLib\src\System\Runtime\CompilerServices\AsyncMethodBuilderCore.cs (3)
111internal static Action CreateContinuationWrapper(Action continuation, Action<Action, Task> invokeAction, Task innerTask) => 140private readonly Action<Action, Task> _invokeAction; // This wrapper is an action that wraps another action, this is that Action. 144internal ContinuationWrapper(Action continuation, Action<Action, Task> invokeAction, Task innerTask)
src\libraries\System.Private.CoreLib\src\System\Security\SecurityElement.cs (1)
410private void ToString(object obj, Action<object, string?> write)
src\libraries\System.Private.CoreLib\src\System\Threading\CancellationToken.cs (2)
200public CancellationTokenRegistration Register(Action<object?, CancellationToken> callback, object? state) => 262public CancellationTokenRegistration UnsafeRegister(Action<object?, CancellationToken> callback, object? state) =>
src\libraries\System.Private.CoreLib\src\System\Threading\CancellationTokenSource.cs (3)
590Debug.Assert(callback is Action<object?> || callback is Action<object?, CancellationToken>); 991Debug.Assert(d is Action<object?> || d is Action<object?, CancellationToken>); 999((Action<object?, CancellationToken>)d)(state, new CancellationToken(source));
src\libraries\System.Private.CoreLib\src\System\Threading\Tasks\Future.cs (6)
808public Task ContinueWith(Action<Task<TResult>, object?> continuationAction, object? state) 832public Task ContinueWith(Action<Task<TResult>, object?> continuationAction, object? state, CancellationToken cancellationToken) 861public Task ContinueWith(Action<Task<TResult>, object?> continuationAction, object? state, TaskScheduler scheduler) 895public Task ContinueWith(Action<Task<TResult>, object?> continuationAction, object? state, TaskContinuationOptions continuationOptions) 936public Task ContinueWith(Action<Task<TResult>, object?> continuationAction, object? state, CancellationToken cancellationToken, 943internal Task ContinueWith(Action<Task<TResult>, object?> continuationAction, object? state, TaskScheduler scheduler, CancellationToken cancellationToken,
src\libraries\System.Private.CoreLib\src\System\Threading\Tasks\Task.cs (6)
3819public Task ContinueWith(Action<Task, object?> continuationAction, object? state) 3842public Task ContinueWith(Action<Task, object?> continuationAction, object? state, CancellationToken cancellationToken) 3870public Task ContinueWith(Action<Task, object?> continuationAction, object? state, TaskScheduler scheduler) 3904public Task ContinueWith(Action<Task, object?> continuationAction, object? state, TaskContinuationOptions continuationOptions) 3945public Task ContinueWith(Action<Task, object?> continuationAction, object? state, CancellationToken cancellationToken, 3952private Task ContinueWith(Action<Task, object?> continuationAction, object? state, TaskScheduler scheduler,
src\libraries\System.Private.CoreLib\src\System\Threading\Tasks\TaskContinuation.cs (4)
18Debug.Assert(action is Action<Task> || action is Action<Task, object?>, 46if (m_action is Action<Task, object?> actionWithState) 110Debug.Assert(action is Action<Task<TAntecedentResult>> || action is Action<Task<TAntecedentResult>, object?>, 138if (m_action is Action<Task<TAntecedentResult>, object?> actionWithState)
System.Private.DataContractSerialization (2)
System\Runtime\Serialization\AccessorBuilder.cs (2)
203var setMethod = propInfo.SetMethod!.CreateDelegate<Action<DeclaringType, PropertyType>>();
System.Private.Windows.Core (1)
System\Private\Windows\BinaryFormat\BinaryFormatWriter.cs (1)
781public static bool TryWrite<T>(Action<Stream, T> action, Stream stream, T value)
System.Private.Xml (4)
System\Xml\Serialization\ReflectionXmlSerializationReader.cs (4)
2085public Action<string, string>? XmlnsSource; 2115Action<TObj, TParam>? setTypedDelegate = null; 2124setTypedDelegate = setMethod.CreateDelegate<Action<TObj, TParam>>(); 2132setTypedDelegate = Expression.Lambda<Action<TObj, TParam>>(assignExpr, objectParam, valueParam).Compile();
System.Reflection.Context (5)
System\Reflection\Context\CustomReflectionContext.cs (2)
66Action<object, object?>? setter) 83Action<object, object?>? setter,
System\Reflection\Context\Virtual\VirtualPropertyInfo.cs (1)
21Action<object, object?>? setter,
System\Reflection\Context\Virtual\VirtualPropertyInfo.PropertySetter.cs (2)
15private readonly Action<object, object?> _setter; 19public PropertySetter(VirtualPropertyBase property, Action<object, object?> setter, IEnumerable<Attribute>? setterAttributes)
System.Reflection.Metadata (1)
System\Reflection\PortableExecutable\DebugDirectory\DebugDirectoryBuilder.cs (1)
58public void AddEntry<TData>(DebugDirectoryEntryType type, uint version, uint stamp, TData data, Action<BlobBuilder, TData> dataSerializer)
System.Runtime (1)
artifacts\obj\System.Runtime\Debug\net10.0\System.Runtime.Forwards.cs (1)
19[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)
286public void ToManaged<T1, T2>(out Action<T1, T2>? value, ArgumentToJSCallback<T1> arg1Marshaler, ArgumentToJSCallback<T2> arg2Marshaler) { throw new System.PlatformNotSupportedException(System.SR.SystemRuntimeInteropServicesJavaScript_PlatformNotSupported); } 287public void ToJS<T1, T2>(Action<T1, T2>? value, ArgumentToManagedCallback<T1> arg1Marshaler, ArgumentToManagedCallback<T2> arg2Marshaler) { throw new System.PlatformNotSupportedException(System.SR.SystemRuntimeInteropServicesJavaScript_PlatformNotSupported); }
System.Security.Cryptography (10)
src\libraries\Common\src\System\Security\Cryptography\Asn1\DirectoryStringAsn.xml.cs (1)
24Action<Asn1Tag, string> ensureUniqueTag = (tag, fieldName) =>
src\libraries\Common\src\System\Security\Cryptography\Asn1\ECDomainParameters.xml.cs (1)
21Action<Asn1Tag, string> ensureUniqueTag = (tag, fieldName) =>
src\libraries\Common\src\System\Security\Cryptography\Asn1\GeneralNameAsn.xml.cs (1)
28Action<Asn1Tag, string> ensureUniqueTag = (tag, fieldName) =>
src\libraries\Common\src\System\Security\Cryptography\Asn1\MLDsaPrivateKeyAsn.xml.cs (1)
22Action<Asn1Tag, string> ensureUniqueTag = (tag, fieldName) =>
src\libraries\Common\src\System\Security\Cryptography\Asn1\MLKemPrivateKeyAsn.xml.cs (1)
22Action<Asn1Tag, string> ensureUniqueTag = (tag, fieldName) =>
src\libraries\Common\src\System\Security\Cryptography\Asn1\Pbkdf2SaltChoice.xml.cs (1)
21Action<Asn1Tag, string> ensureUniqueTag = (tag, fieldName) =>
src\libraries\Common\src\System\Security\Cryptography\Asn1\Pkcs7\CertificateChoiceAsn.xml.cs (1)
24Action<Asn1Tag, string> ensureUniqueTag = (tag, fieldName) =>
src\libraries\Common\src\System\Security\Cryptography\Asn1\Pkcs7\SignerIdentifierAsn.xml.cs (1)
21Action<Asn1Tag, string> ensureUniqueTag = (tag, fieldName) =>
System\Security\Cryptography\X509Certificates\Asn1\DistributionPointNameAsn.xml.cs (1)
22Action<Asn1Tag, string> ensureUniqueTag = (tag, fieldName) =>
System\Security\Cryptography\X509Certificates\Asn1\TimeAsn.xml.cs (1)
21Action<Asn1Tag, string> ensureUniqueTag = (tag, fieldName) =>
System.Security.Cryptography.Pkcs (10)
src\libraries\Common\src\System\Security\Cryptography\Asn1\DirectoryStringAsn.xml.cs (1)
24Action<Asn1Tag, string> ensureUniqueTag = (tag, fieldName) =>
src\libraries\Common\src\System\Security\Cryptography\Asn1\GeneralNameAsn.xml.cs (1)
28Action<Asn1Tag, string> ensureUniqueTag = (tag, fieldName) =>
src\libraries\Common\src\System\Security\Cryptography\Asn1\Pbkdf2SaltChoice.xml.cs (1)
21Action<Asn1Tag, string> ensureUniqueTag = (tag, fieldName) =>
src\libraries\Common\src\System\Security\Cryptography\Asn1\Pkcs7\CertificateChoiceAsn.xml.cs (1)
24Action<Asn1Tag, string> ensureUniqueTag = (tag, fieldName) =>
src\libraries\Common\src\System\Security\Cryptography\Asn1\Pkcs7\SignerIdentifierAsn.xml.cs (1)
21Action<Asn1Tag, string> ensureUniqueTag = (tag, fieldName) =>
System\Security\Cryptography\Pkcs\Asn1\KeyAgreeRecipientIdentifierAsn.xml.cs (1)
21Action<Asn1Tag, string> ensureUniqueTag = (tag, fieldName) =>
System\Security\Cryptography\Pkcs\Asn1\OriginatorIdentifierOrKeyAsn.xml.cs (1)
22Action<Asn1Tag, string> ensureUniqueTag = (tag, fieldName) =>
System\Security\Cryptography\Pkcs\Asn1\RecipientIdentifierAsn.xml.cs (1)
21Action<Asn1Tag, string> ensureUniqueTag = (tag, fieldName) =>
System\Security\Cryptography\Pkcs\Asn1\RecipientInfoAsn.xml.cs (1)
21Action<Asn1Tag, string> ensureUniqueTag = (tag, fieldName) =>
System\Security\Cryptography\Pkcs\Asn1\SignedAttributesSet.xml.cs (1)
21Action<Asn1Tag, string> ensureUniqueTag = (tag, fieldName) =>
System.ServiceModel.Federation (2)
System\Runtime\OperationWithTimeoutAsyncResult.cs (2)
111protected Action<AsyncResult, Exception> OnCompleting { get; set; } 122protected Action<AsyncCallback, IAsyncResult> VirtualCallback
System.ServiceModel.Primitives (8)
Internals\System\Runtime\AsyncResult.cs (2)
73protected Action<AsyncResult, Exception> OnCompleting { get; set; } 84protected Action<AsyncCallback, IAsyncResult> VirtualCallback
Internals\System\Runtime\InputQueue.cs (2)
34public InputQueue(Func<Action<AsyncCallback, IAsyncResult>> asyncCallbackGenerator) 60private Func<Action<AsyncCallback, IAsyncResult>> AsyncCallbackGenerator
System\ServiceModel\Diagnostics\TraceAsyncResult.cs (1)
12private static Action<AsyncCallback, IAsyncResult> s_waitResultCallback = new Action<AsyncCallback, IAsyncResult>(DoCallback);
System\ServiceModel\Diagnostics\TraceUtility.cs (3)
32public static Func<Action<AsyncCallback, IAsyncResult>> asyncCallbackGenerator; 391asyncCallbackGenerator = new Func<Action<AsyncCallback, IAsyncResult>>(CallbackGenerator); 406internal static Action<AsyncCallback, IAsyncResult> CallbackGenerator()
System.Text.Json (35)
System\Text\Json\Serialization\Converters\Collection\StackOrQueueConverter.cs (2)
18var addMethodDelegate = ((Action<TCollection, object?>?)state.Current.JsonTypeInfo.AddMethodDelegate);
System\Text\Json\Serialization\Metadata\JsonCollectionInfoValuesOfTCollection.cs (1)
44public Action<Utf8JsonWriter, TCollection>? SerializeHandler { get; init; }
System\Text\Json\Serialization\Metadata\JsonMetadataServices.Collections.cs (3)
371Action<TCollection, object?> addFunc) 389Action<TCollection, object?> addFunc) 396Action<TCollection, object?> addFunc)
System\Text\Json\Serialization\Metadata\JsonObjectInfoValuesOfT.cs (1)
56public Action<Utf8JsonWriter, T>? SerializeHandler { get; init; }
System\Text\Json\Serialization\Metadata\JsonPropertyInfo.cs (2)
88public Action<object, object?>? Set 100private protected Action<object, object?>? _untypedSet;
System\Text\Json\Serialization\Metadata\JsonPropertyInfoOfT.cs (8)
17private Action<object, T>? _typedSet; 30internal new Action<object, T>? Set 61Debug.Assert(setter is null or Action<object, object?> or Action<object, T>); 69else if (setter is Action<object, T> typedSetter) 72_untypedSet = setter is Action<object, object?> untypedSet ? untypedSet : (obj, value) => typedSetter(obj, (T)value!); 76Action<object, object?> untypedSet = (Action<object, object?>)setter;
System\Text\Json\Serialization\Metadata\JsonPropertyInfoValuesOfT.cs (1)
54public Action<object, T?>? Setter { get; init; }
System\Text\Json\Serialization\Metadata\JsonTypeInfoOfT.cs (2)
15private Action<Utf8JsonWriter, T>? _serialize; 124public Action<Utf8JsonWriter, T>? SerializeHandler
System\Text\Json\Serialization\Metadata\MemberAccessor.cs (3)
18public abstract Action<TCollection, object?> CreateAddMethodDelegate<[DynamicallyAccessedMembers(DynamicallyAccessedMemberTypes.PublicMethods)] TCollection>(); 26public abstract Action<object, TProperty> CreatePropertySetter<TProperty>(PropertyInfo propertyInfo); 30public abstract Action<object, TProperty> CreateFieldSetter<TProperty>(FieldInfo fieldInfo);
System\Text\Json\Serialization\Metadata\ReflectionEmitCachingMemberAccessor.cs (3)
26public override Action<TCollection, object?> CreateAddMethodDelegate<[DynamicallyAccessedMembers(DynamicallyAccessedMemberTypes.PublicMethods)] TCollection>() => 41public override Action<object, TProperty> CreateFieldSetter<TProperty>(FieldInfo fieldInfo) => 71public override Action<object, TProperty> CreatePropertySetter<TProperty>(PropertyInfo propertyInfo) =>
System\Text\Json\Serialization\Metadata\ReflectionEmitMemberAccessor.cs (6)
156public override Action<TCollection, object?> CreateAddMethodDelegate<[DynamicallyAccessedMembers(DynamicallyAccessedMemberTypes.PublicMethods)] TCollection>() => 157CreateDelegate<Action<TCollection, object?>>(CreateAddMethodDelegate(typeof(TCollection))); 276public override Action<object, TProperty> CreatePropertySetter<TProperty>(PropertyInfo propertyInfo) => 277CreateDelegate<Action<object, TProperty>>(CreatePropertySetter(propertyInfo, typeof(TProperty))); 348public override Action<object, TProperty> CreateFieldSetter<TProperty>(FieldInfo fieldInfo) => 349CreateDelegate<Action<object, TProperty>>(CreateFieldSetter(fieldInfo, typeof(TProperty)));
System\Text\Json\Serialization\Metadata\ReflectionMemberAccessor.cs (3)
115public override Action<TCollection, object?> CreateAddMethodDelegate<[DynamicallyAccessedMembers(DynamicallyAccessedMemberTypes.PublicMethods)] TCollection>() 153public override Action<object, TProperty> CreatePropertySetter<TProperty>(PropertyInfo propertyInfo) 169public override Action<object, TProperty> CreateFieldSetter<TProperty>(FieldInfo fieldInfo) =>
System.Text.RegularExpressions (3)
System\Text\RegularExpressions\Symbolic\SymbolicRegexMatcher.Automata.cs (1)
462private void ForEachNfaState<T>(SymbolicRegexNode<TSet> node, uint prevCharKind, T arg, Action<int, T> action)
System\Text\RegularExpressions\Symbolic\SymbolicRegexNode.cs (1)
1531internal void ApplyEffects<TArg>(Action<DerivativeEffect, TArg> apply, uint context, TArg arg)
System\Threading\StackHelper.cs (1)
49public static void CallOnEmptyStack<TArg1, TArg2>(Action<TArg1, TArg2> action, TArg1 arg1, TArg2 arg2) =>
System.Text.RegularExpressions.Generator (1)
src\libraries\System.Text.RegularExpressions\src\System\Threading\StackHelper.cs (1)
49public static void CallOnEmptyStack<TArg1, TArg2>(Action<TArg1, TArg2> action, TArg1 arg1, TArg2 arg2) =>
System.Threading.Channels (12)
System\Threading\Channels\AsyncOperation.cs (7)
104Action<object?, CancellationToken>? cancellationCallback) 414protected AsyncOperation(bool runContinuationsAsynchronously, CancellationToken cancellationToken = default, bool pooled = false, Action<object?, CancellationToken>? cancellationCallback = null) : 480public AsyncOperation(bool runContinuationsAsynchronously, CancellationToken cancellationToken = default, bool pooled = false, Action<object?, CancellationToken>? cancellationCallback = null) : 561public BlockedReadAsyncOperation(bool runContinuationsAsynchronously, CancellationToken cancellationToken = default, bool pooled = false, Action<object?, CancellationToken>? cancellationCallback = null) : 572public BlockedWriteAsyncOperation(bool runContinuationsAsynchronously, CancellationToken cancellationToken = default, bool pooled = false, Action<object?, CancellationToken>? cancellationCallback = null) : 585public WaitingReadAsyncOperation(bool runContinuationsAsynchronously, CancellationToken cancellationToken = default, bool pooled = false, Action<object?, CancellationToken>? cancellationCallback = null) : 595public WaitingWriteAsyncOperation(bool runContinuationsAsynchronously, CancellationToken cancellationToken = default, bool pooled = false, Action<object?, CancellationToken>? cancellationCallback = null) :
System\Threading\Channels\BoundedChannel.cs (1)
655private Action<object?, CancellationToken> CancellationCallbackDelegate =>
System\Threading\Channels\RendezvousChannel.cs (1)
449private Action<object?, CancellationToken> CancellationCallbackDelegate =>
System\Threading\Channels\SingleConsumerUnboundedChannel.cs (1)
364private Action<object?, CancellationToken> CancellationCallbackDelegate =>
System\Threading\Channels\UnboundedChannel.cs (1)
302private Action<object?, CancellationToken> CancellationCallbackDelegate =>
System\Threading\Channels\UnboundedPriorityChannel.cs (1)
308private Action<object?, CancellationToken> CancellationCallbackDelegate =>
System.Threading.Tasks.Dataflow (15)
Blocks\BatchBlock.cs (1)
57Action<ISourceBlock<T[]>, int>? onItemsRemoved = null;
Blocks\BufferBlock.cs (1)
54Action<ISourceBlock<T>, int>? onItemsRemoved = null;
Blocks\JoinBlock.cs (2)
58Action<ISourceBlock<Tuple<T1, T2>>, int>? onItemsRemoved = null; 279Action<ISourceBlock<Tuple<T1, T2, T3>>, int>? onItemsRemoved = null;
Blocks\TransformBlock.cs (1)
104Action<ISourceBlock<TOutput>, int>? onItemsRemoved = null;
Blocks\TransformManyBlock.cs (1)
112Action<ISourceBlock<TOutput>, int>? onItemsRemoved = null;
Internal\ActionOnDispose.cs (4)
31internal static IDisposable Create<T1, T2>(Action<T1, T2> action, T1 arg1, T2 arg2) 68private Action<T1, T2>? _action; 74internal Disposable(Action<T1, T2> action, T1 arg1, T2 arg2) 88Action<T1, T2>? toRun = _action;
Internal\Common.cs (1)
176CancellationToken cancellationToken, Task completionTask, Action<object?, CancellationToken> completeAction, object completeState)
Internal\ReorderingBuffer.cs (2)
46private readonly Action<object, TOutput> _outputAction; 56internal ReorderingBuffer(object owningSource, Action<object, TOutput> outputAction)
Internal\SourceCore.cs (2)
72private readonly Action<ISourceBlock<TOutput>, int>? _itemsRemovedAction; 105Action<ISourceBlock<TOutput>, int>? itemsRemovedAction = null,
System.Threading.Tasks.Parallel (13)
System\Threading\Tasks\Parallel.cs (13)
537public static ParallelLoopResult For(int fromInclusive, int toExclusive, Action<int, ParallelLoopState> body) 564public static ParallelLoopResult For(long fromInclusive, long toExclusive, Action<long, ParallelLoopState> body) 602public static ParallelLoopResult For(int fromInclusive, int toExclusive, ParallelOptions parallelOptions, Action<int, ParallelLoopState> body) 642Action<long, ParallelLoopState> body) 918Action<TInt, ParallelLoopState>? bodyWithState, 1252public static ParallelLoopResult ForEach<TSource>(IEnumerable<TSource> source, Action<TSource, ParallelLoopState> body) 1293public static ParallelLoopResult ForEach<TSource>(IEnumerable<TSource> source, ParallelOptions parallelOptions, Action<TSource, ParallelLoopState> body) 1639Action<TSource, ParallelLoopState>? bodyWithState, 1697Action<TSource, ParallelLoopState>? bodyWithState, 1756Action<TSource, ParallelLoopState>? bodyWithState, 1890Action<TSource, ParallelLoopState> body) 2238Action<TSource, ParallelLoopState> body) 2510Action<TSource, ParallelLoopState>? bodyWithState,
System.Windows.Forms (1)
System\Windows\Forms\Controls\ToolStrips\ToolStrip.cs (1)
109internal Action<int, int>? _rescaleConstsCallbackDelegate;
System.Windows.Forms.Tests (12)
System\Windows\Forms\FormTests.cs (5)
2614yield return new Action<Form, Control>[] 2618yield return new Action<Form, Control>[] 2624yield return new Action<Form, Control>[] 2628yield return new Action<Form, Control>[] 2636public void Form_Show_SetsOwnerToTopLevelForm_WhenShownWithOwner(Action<Form, Control> showAction)
System\Windows\Forms\ListControlTests.cs (1)
3012public Action<int, object> SetItemCoreHandler { get; set; }
System\Windows\Forms\MonthCalendarTests.cs (2)
4576private void TestResetColorProperty(Func<MonthCalendar, Color> getColor, Action<MonthCalendar, Color> setColor, Action<dynamic> resetColor) 4625private void TestResetProperty<T>(MonthCalendar calendar, Action<MonthCalendar, T> setProperty, Func<MonthCalendar, T> getProperty, T testValue, T expectedValue, Action<dynamic> resetProperty)
System\Windows\Forms\ProgressBarRendererTest.cs (1)
66private void TestProgressBarRenderer(Action<Graphics, Rectangle> drawAction)
System\Windows\Forms\TrackBarRendererTests.cs (2)
36void TestDrawTrack(Action<Graphics, Rectangle> drawTrack, Rectangle bounds) 49void TestDrawTrackWithInvalidBounds(Action<Graphics, Rectangle> drawTrack, Rectangle[] invalidBounds)
System\Windows\Forms\UpDownBaseTests.cs (1)
3058public Action<object, EventArgs> OnChangedAction { get; set; }
System.Windows.Input.Manipulations (2)
System\Windows\Input\Manipulations\InertiaParameters2D.cs (1)
17internal event Action<InertiaParameters2D, string> Changed;
System\Windows\Input\Manipulations\InertiaProcessor2D.cs (1)
409Action<InertiaParameters2D, string> handler,
Test.Utilities (19)
src\Dependencies\PooledObjects\PooledDelegates.cs (8)
98public static Releaser GetPooledAction<T1, TArg>(Action<T1, TArg> unboundAction, TArg argument, out Action<T1> boundAction) 99=> GetPooledDelegate<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>>(unboundAction, argument, out boundAction); 102/// Gets an <see cref="Action{T1, T2}"/> delegate, which calls <paramref name="unboundAction"/> with the specified 132public static Releaser GetPooledAction<T1, T2, TArg>(Action<T1, T2, TArg> unboundAction, TArg argument, out Action<T1, T2> boundAction) 133=> GetPooledDelegate<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>>(unboundAction, argument, out boundAction); 391: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>> 398: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>> 400protected override Action<T1, T2> Bind()
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Extensions\ObjectWriterExtensions.cs (1)
13public static void WriteArray<T>(this ObjectWriter writer, ImmutableArray<T> values, Action<ObjectWriter, T> write)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\FlowAnalysis\SymbolUsageAnalysis\SymbolUsageAnalysis.BasicBlockAnalysisData.cs (1)
74public void ForEachCurrentWrite<TArg>(ISymbol symbol, Action<IOperation, TArg> action, TArg arg)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Formatting\Engine\AbstractFormatEngine.cs (6)
167var addIndentBlockOperations = _formattingRules.AddIndentBlockOperations; 168var addSuppressOperation = _formattingRules.AddSuppressOperations; 169var addAlignTokensOperations = _formattingRules.AddAlignTokensOperations; 170var addAnchorIndentationOperations = _formattingRules.AddAnchorIndentationOperations; 189private static void AddOperations<T>(SegmentedList<T> operations, List<T> scratch, SyntaxNode node, Action<List<T>, SyntaxNode> addOperations) 203private static void AddOperations<T>(SegmentedList<T> operations, ArrayBuilder<T> scratch, SyntaxNode node, Action<ArrayBuilder<T>, SyntaxNode> addOperations)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\NamingStyles\Serialization\NamingStylePreferencesEditorConfigSerializer.cs (1)
51Action<string, string> entryWriter,
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\ObjectPools\PooledObject.cs (2)
19private readonly Action<ObjectPool<T>, T> _releaser; 22public PooledObject(ObjectPool<T> pool, Func<ObjectPool<T>, T> allocator, Action<ObjectPool<T>, T> releaser) : this()
Text.Analyzers (21)
src\Dependencies\PooledObjects\PooledDelegates.cs (8)
98public static Releaser GetPooledAction<T1, TArg>(Action<T1, TArg> unboundAction, TArg argument, out Action<T1> boundAction) 99=> GetPooledDelegate<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>>(unboundAction, argument, out boundAction); 102/// Gets an <see cref="Action{T1, T2}"/> delegate, which calls <paramref name="unboundAction"/> with the specified 132public static Releaser GetPooledAction<T1, T2, TArg>(Action<T1, T2, TArg> unboundAction, TArg argument, out Action<T1, T2> boundAction) 133=> GetPooledDelegate<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>>(unboundAction, argument, out boundAction); 391: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, TArg>, TArg, Action<T1, TArg>, Action<T1>> 398: AbstractDelegateWithBoundArgument<ActionWithBoundArgument<T1, T2, TArg>, TArg, Action<T1, T2, TArg>, Action<T1, T2>> 400protected override Action<T1, T2> Bind()
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Extensions\ObjectWriterExtensions.cs (1)
13public static void WriteArray<T>(this ObjectWriter writer, ImmutableArray<T> values, Action<ObjectWriter, T> write)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\FlowAnalysis\SymbolUsageAnalysis\SymbolUsageAnalysis.BasicBlockAnalysisData.cs (1)
74public void ForEachCurrentWrite<TArg>(ISymbol symbol, Action<IOperation, TArg> action, TArg arg)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Formatting\Engine\AbstractFormatEngine.cs (6)
167var addIndentBlockOperations = _formattingRules.AddIndentBlockOperations; 168var addSuppressOperation = _formattingRules.AddSuppressOperations; 169var addAlignTokensOperations = _formattingRules.AddAlignTokensOperations; 170var addAnchorIndentationOperations = _formattingRules.AddAnchorIndentationOperations; 189private static void AddOperations<T>(SegmentedList<T> operations, List<T> scratch, SyntaxNode node, Action<List<T>, SyntaxNode> addOperations) 203private static void AddOperations<T>(SegmentedList<T> operations, ArrayBuilder<T> scratch, SyntaxNode node, Action<ArrayBuilder<T>, SyntaxNode> addOperations)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\NamingStyles\Serialization\NamingStylePreferencesEditorConfigSerializer.cs (1)
51Action<string, string> entryWriter,
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\ObjectPools\PooledObject.cs (2)
19private readonly Action<ObjectPool<T>, T> _releaser; 22public PooledObject(ObjectPool<T> pool, Func<ObjectPool<T>, T> allocator, Action<ObjectPool<T>, T> releaser) : this()
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Extensions\StringBuilderExtensions.cs (2)
21this StringBuilder builder, string separator, SeparatedSyntaxList<TNode> values, Action<TNode, StringBuilder> append) 37public static StringBuilder AppendJoinedValues<T>(this StringBuilder builder, string separator, ImmutableArray<T> values, Action<T, StringBuilder> append)
UnitTests.Common (6)
MockClientMessageInspector.cs (3)
28public Action<ServiceEndpoint, BindingParameterCollection> AddBindingParametersOverride { get; set; } 29public Action<ServiceEndpoint, EndpointDispatcher> ApplyDispatchBehaviorOverride { get; set; } 30public Action<ServiceEndpoint, ClientRuntime> ApplyClientBehaviorOverride { get; set; }
MockEndpointBehavior.cs (3)
21public Action<ServiceEndpoint, BindingParameterCollection> AddBindingParametersOverride { get; set; } 22public Action<ServiceEndpoint, EndpointDispatcher> ApplyDispatchBehaviorOverride { get; set; } 23public Action<ServiceEndpoint, ClientRuntime> ApplyClientBehaviorOverride { get; set; }
WindowsBase.Tests (8)
System\Collections\Specialized\CollectionChangedEventManagerTests.cs (1)
566public Action<object, NotifyCollectionChangedEventArgs>? HandlerAction { get; set; }
System\ComponentModel\CurrentChangedEventManagerTests.cs (1)
641public Action<object, EventArgs>? HandlerAction { get; set; }
System\ComponentModel\CurrentChangingEventManagerTests.cs (1)
623public Action<object, CurrentChangingEventArgs>? HandlerAction { get; set; }
System\ComponentModel\ErrorsChangedEventManagerTests.cs (1)
285public Action<object, DataErrorsChangedEventArgs>? HandlerAction { get; set; }
System\ComponentModel\PropertyChangedEventManagerTests.cs (1)
1272public Action<object, PropertyChangedEventArgs>? HandlerAction { get; set; }
System\Windows\Threading\DispatcherTests.cs (2)
146Assert.Throws<InvalidEnumArgumentException>("priority", () => dispatcher.BeginInvoke(priority, (Action<object, object>)((arg1, arg2) => { }), new object(), new object[] { new object() })); 147Assert.Throws<InvalidEnumArgumentException>("priority", () => dispatcher.BeginInvoke(priority, (Action<object, object>)((arg1, arg2) => { }), new object[] { new object(), new object() }));
System\Windows\WeakEventManagerTests.cs (1)
6078public Action<object, EventArgs>? HandlerAction { get; set; }
xunit.assert (3)
AsyncCollectionAsserts.cs (1)
50 Action<T, int> action) =>
CollectionAsserts.cs (1)
68 Action<T, int> action)
Sdk\Exceptions\AllException.cs (1)
34 /// or <see cref="Assert.All{T}(IEnumerable{T}, Action{T, int})"/>,
xunit.console (1)
Utility\Transform.cs (1)
13public Action<XElement, string> OutputHandler;