714 references to Func
Aspire.Cli.Tests (2)
TestServices\TestDotNetCliRunner.cs (2)
13public Func<FileInfo, DotNetCliRunnerInvocationOptions, CancellationToken, int>? BuildAsyncCallback { get; set; } 15public Func<FileInfo, DotNetCliRunnerInvocationOptions, CancellationToken, (int ExitCode, bool IsAspireHost, string? AspireHostingSdkVersion)>? GetAppHostInformationAsyncCallback { get; set; }
Aspire.Hosting.Azure.Tests (2)
ExistingAzureResourceExtensionsTests.cs (2)
104public static TheoryData<Func<string, string, string, IResourceBuilder<IAzureResource>>> AsExistingMethodsWithString => 113public void CanCallAsExistingWithStringArguments(Func<string, string, string, IResourceBuilder<IAzureResource>> runAsExisting)
Aspire.Microsoft.Data.SqlClient (4)
src\Vendoring\OpenTelemetry.Instrumentation.SqlClient\Shared\DiagnosticSourceInstrumentation\DiagnosticSourceSubscriber.cs (3)
16private readonly Func<string, object, object, bool> isEnabledFilter; 23Func<string, object, object, bool> isEnabledFilter, 32Func<string, object, object, bool> isEnabledFilter,
src\Vendoring\OpenTelemetry.Instrumentation.SqlClient\SqlClientInstrumentation.cs (1)
35private readonly Func<string, object, object, bool> isEnabled = (eventName, _, _)
Aspire.Microsoft.EntityFrameworkCore.SqlServer (4)
src\Vendoring\OpenTelemetry.Instrumentation.SqlClient\Shared\DiagnosticSourceInstrumentation\DiagnosticSourceSubscriber.cs (3)
16private readonly Func<string, object, object, bool> isEnabledFilter; 23Func<string, object, object, bool> isEnabledFilter, 32Func<string, object, object, bool> isEnabledFilter,
src\Vendoring\OpenTelemetry.Instrumentation.SqlClient\SqlClientInstrumentation.cs (1)
35private readonly Func<string, object, object, bool> isEnabled = (eventName, _, _)
illink (3)
ILLink.RoslynAnalyzer (3)
src\tools\illink\src\ILLink.Shared\TrimAnalysis\IntrinsicId.cs (3)
69 /// <item><see cref="System.Type.GetType(string, System.Func{System.Reflection.AssemblyName, System.Reflection.Assembly?}?, System.Func{System.Reflection.Assembly?, string, bool, System.Type?}?)"/></item> 70 /// <item><see cref="System.Type.GetType(string, System.Func{System.Reflection.AssemblyName, System.Reflection.Assembly?}?, System.Func{System.Reflection.Assembly?, string, bool, System.Type?}?, bool)"/></item> 71 /// <item><see cref="System.Type.GetType(string, System.Func{System.Reflection.AssemblyName, System.Reflection.Assembly?}?, System.Func{System.Reflection.Assembly?, string, bool, System.Type?}?, bool, bool)"/></item>
Microsoft.Analyzers.Extra (2)
CallAnalysis\Fixers\LegacyLoggingFixer.cs (2)
41internal Func<SemanticModel, SyntaxNode, CancellationToken, IOperation?> GetOperation = (sm, sn, t) => sm.GetOperation(sn, t); 45internal Func<SemanticModel, BaseMethodDeclarationSyntax, CancellationToken, IMethodSymbol?> GetDeclaredSymbol = (sm, m, t) => sm.GetDeclaredSymbol(m, t);
Microsoft.AspNetCore.Diagnostics.Middleware.Tests (1)
Logging\AcceptanceTests.cs (1)
149Func<FakeLogCollector, HttpClient, IServiceProvider, Task> func)
Microsoft.AspNetCore.Http (1)
Internal\ResponseCookies.cs (1)
120Func<string, string, CookieOptions, bool> rejectPredicate;
Microsoft.AspNetCore.Http.Abstractions (4)
Extensions\UseMiddlewareExtensions.cs (4)
139var factory = RuntimeFeature.IsDynamicCodeCompiled 200private static Func<T, HttpContext, IServiceProvider, Task> ReflectionFallback<T>(MethodInfo methodInfo, ParameterInfo[] parameters) 265private static Func<T, HttpContext, IServiceProvider, Task> CompileExpression<T>(MethodInfo methodInfo, ParameterInfo[] parameters) 323var lambda = Expression.Lambda<Func<T, HttpContext, IServiceProvider, Task>>(body, instanceArg, httpContextArg, providerArg);
Microsoft.AspNetCore.Http.Extensions (6)
RequestDelegateFactory.cs (6)
1259var continuation = Expression.Lambda<Func<object?, HttpContext, object?[], Task>>( 1344var continuation = Expression.Lambda<Func<object?, HttpContext, object?, Task>>( 1476var continuation = Expression.Lambda<Func<object?, HttpContext, object?, Task>>(
Microsoft.AspNetCore.JsonPatch (1)
Internal\DynamicObjectAdapter.cs (1)
222var callsite = CallSite<Func<CallSite, object, object, object>>.Create(binder);
Microsoft.AspNetCore.Mvc.Core.Test (2)
Routing\DynamicControllerEndpointMatcherPolicyTest.cs (2)
92private Func<HttpContext, RouteValueDictionary, object, ValueTask<RouteValueDictionary>> Transform { get; set; } 447public Func<HttpContext, RouteValueDictionary, object, ValueTask<RouteValueDictionary>> Transform { get; set; }
Microsoft.AspNetCore.Mvc.RazorPages (9)
Infrastructure\DefaultPageActivatorProvider.cs (3)
16private readonly Func<PageContext, ViewContext, object, ValueTask> _asyncDisposer = AsyncDispose; 17private readonly Func<PageContext, ViewContext, object, ValueTask> _syncAsyncDisposer = SyncAsyncDispose; 48public Func<PageContext, ViewContext, object, ValueTask>? CreateAsyncReleaser(CompiledPageActionDescriptor actionDescriptor)
Infrastructure\DefaultPageFactoryProvider.cs (1)
77public Func<PageContext, ViewContext, object, ValueTask>? CreateAsyncPageDisposer(CompiledPageActionDescriptor descriptor)
Infrastructure\PageActionInvokerCache.cs (1)
78var pageDisposer = _pageFactoryProvider.CreateAsyncPageDisposer(compiledActionDescriptor);
Infrastructure\PageActionInvokerCacheEntry.cs (2)
18Func<PageContext, ViewContext, object, ValueTask>? releasePage, 47public Func<PageContext, ViewContext, object, ValueTask>? ReleasePage { get; }
IPageActivatorProvider.cs (1)
32Func<PageContext, ViewContext, object, ValueTask>? CreateAsyncReleaser(CompiledPageActionDescriptor descriptor)
IPageFactoryProvider.cs (1)
32Func<PageContext, ViewContext, object, ValueTask>? CreateAsyncPageDisposer(CompiledPageActionDescriptor descriptor)
Microsoft.AspNetCore.Mvc.RazorPages.Test (9)
Infrastructure\DefaultPageActivatorProviderTest.cs (4)
97var releaser = activator.CreateAsyncReleaser(new CompiledPageActionDescriptor 137var disposer = activator.CreateAsyncReleaser(new CompiledPageActionDescriptor 158var disposer = activator.CreateAsyncReleaser(new CompiledPageActionDescriptor 179var disposer = activator.CreateAsyncReleaser(new CompiledPageActionDescriptor
Infrastructure\DefaultPageFactoryProviderTest.cs (1)
358var disposer = factoryProvider.CreateAsyncPageDisposer(pageContext.ActionDescriptor);
Infrastructure\DynamicPageEndpointMatcherPolicyTest.cs (2)
111private Func<HttpContext, RouteValueDictionary, object, ValueTask<RouteValueDictionary>> Transform { get; set; } 447public Func<HttpContext, RouteValueDictionary, object, ValueTask<RouteValueDictionary>> Transform { get; set; }
Infrastructure\PageActionInvokerProviderTest.cs (2)
37Func<PageContext, ViewContext, object, ValueTask> releaser = (a, b, c) => default; 89Func<PageContext, ViewContext, object, ValueTask> releaser = (a, b, c) => default;
Microsoft.AspNetCore.OpenApi (14)
Extensions\OpenApiEndpointConventionBuilderExtensions.cs (2)
130/// <param name="transformer">The <see cref="Func{OpenApiOperation, OpenApiOperationTransformerContext, CancellationToken, Task}"/> that modifies the operation in the <see cref="OpenApiDocument"/>.</param> 132public static TBuilder AddOpenApiOperationTransformer<TBuilder>(this TBuilder builder, Func<OpenApiOperation, OpenApiOperationTransformerContext, CancellationToken, Task> transformer) where TBuilder : IEndpointConventionBuilder
Services\OpenApiDocumentService.cs (1)
159Func<OpenApiOperation, OpenApiOperationTransformerContext, CancellationToken, Task> callback,
Services\OpenApiOptions.cs (3)
91public OpenApiOptions AddDocumentTransformer(Func<OpenApiDocument, OpenApiDocumentTransformerContext, CancellationToken, Task> transformer) 129public OpenApiOptions AddOperationTransformer(Func<OpenApiOperation, OpenApiOperationTransformerContext, CancellationToken, Task> transformer) 167public OpenApiOptions AddSchemaTransformer(Func<OpenApiSchema, OpenApiSchemaTransformerContext, CancellationToken, Task> transformer)
Transformers\DelegateOpenApiDocumentTransformer.cs (4)
11private readonly Func<OpenApiDocument, OpenApiDocumentTransformerContext, CancellationToken, Task>? _documentTransformer; 12private readonly Func<OpenApiOperation, OpenApiOperationTransformerContext, CancellationToken, Task>? _operationTransformer; 14public DelegateOpenApiDocumentTransformer(Func<OpenApiDocument, OpenApiDocumentTransformerContext, CancellationToken, Task> transformer) 19public DelegateOpenApiDocumentTransformer(Func<OpenApiOperation, OpenApiOperationTransformerContext, CancellationToken, Task> transformer)
Transformers\DelegateOpenApiOperationTransformer.cs (2)
10private readonly Func<OpenApiOperation, OpenApiOperationTransformerContext, CancellationToken, Task> _transformer; 12public DelegateOpenApiOperationTransformer(Func<OpenApiOperation, OpenApiOperationTransformerContext, CancellationToken, Task> transformer)
Transformers\DelegateOpenApiSchemaTransformer.cs (2)
10private readonly Func<OpenApiSchema, OpenApiSchemaTransformerContext, CancellationToken, Task> _transformer; 12public DelegateOpenApiSchemaTransformer(Func<OpenApiSchema, OpenApiSchemaTransformerContext, CancellationToken, Task> transformer)
Microsoft.AspNetCore.OpenApi.Tests (4)
Transformers\OpenApiOptionsTests.cs (3)
14var transformer = new Func<OpenApiDocument, OpenApiDocumentTransformerContext, CancellationToken, Task>((document, context, cancellationToken) => 71var transformer = new Func<OpenApiOperation, OpenApiOperationTransformerContext, CancellationToken, Task>((operation, context, cancellationToken) => 128var transformer = new Func<OpenApiSchema, OpenApiSchemaTransformerContext, CancellationToken, Task>((schema, context, cancellationToken) =>
Transformers\SchemaTransformerTests.cs (1)
755static void UseNotSchemaTransformer(OpenApiOptions options, Func<OpenApiSchema, OpenApiSchemaTransformerContext, CancellationToken, Task> func)
Microsoft.AspNetCore.OutputCaching (3)
Policies\PredicatePolicy.cs (1)
45private ValueTask ExecuteAwaited(Func<IOutputCachePolicy, OutputCacheContext, CancellationToken, ValueTask> action, IOutputCachePolicy policy, OutputCacheContext context, CancellationToken cancellationToken)
Policies\SetCacheKeyPrefixPolicy.cs (1)
13private readonly Func<HttpContext, CacheVaryByRules, CancellationToken, ValueTask> _varyByAsync;
Policies\VaryByValuePolicy.cs (1)
13private readonly Func<HttpContext, CacheVaryByRules, CancellationToken, ValueTask> _varyByAsync;
Microsoft.AspNetCore.Owin (4)
WebSockets\OwinWebSocketAdapter.cs (3)
10Func<int /* closeStatus */, 36private readonly WebSocketCloseAsync _closeAsync; 50_closeAsync = (WebSocketCloseAsync)websocketContext[OwinConstants.WebSocket.CloseAsync];
WebSockets\WebSocketAdapter.cs (1)
10Func<int /* closeStatus */,
Microsoft.AspNetCore.Routing (13)
Builder\RouteHandlerServices.cs (2)
40Func<Delegate, RequestDelegateFactoryOptions, RequestDelegateMetadataResult?, RequestDelegateResult> createRequestDelegate) 70Func<Delegate, RequestDelegateFactoryOptions, RequestDelegateMetadataResult?, RequestDelegateResult> createRequestDelegate,
Matching\ILEmitTrieFactory.cs (3)
26public static Func<string, int, int, int> Create( 43return (Func<string, int, int, int>)method.CreateDelegate(typeof(Func<string, int, int, int>));
Matching\ILEmitTrieJumpTable.cs (1)
80var generated = ILEmitTrieFactory.Create(_defaultDestination, _exitDestination, _entries, _vectorize);
RequestDelegateRouteBuilderExtensions.cs (5)
91Func<HttpRequest, HttpResponse, RouteData, Task> handler) 133Func<HttpRequest, HttpResponse, RouteData, Task> handler) 175Func<HttpRequest, HttpResponse, RouteData, Task> handler) 217Func<HttpRequest, HttpResponse, RouteData, Task> handler) 235Func<HttpRequest, HttpResponse, RouteData, Task> handler)
RouteEndpointDataSource.cs (2)
36Func<Delegate, RequestDelegateFactoryOptions, RequestDelegateMetadataResult?, RequestDelegateResult> createHandlerRequestDelegateFunc, 64Func<Delegate, RequestDelegateFactoryOptions, RequestDelegateMetadataResult?, RequestDelegateResult> createHandlerRequestDelegateFunc,
Microsoft.AspNetCore.Routing.Tests (20)
Builder\RequestDelegateEndpointRouteBuilderExtensionsTest.cs (10)
51new object[] { (Func<IEndpointRouteBuilder, string, RequestDelegate, IEndpointConventionBuilder>)MapGet }, 52new object[] { (Func<IEndpointRouteBuilder, string, RequestDelegate, IEndpointConventionBuilder>)MapPost }, 53new object[] { (Func<IEndpointRouteBuilder, string, RequestDelegate, IEndpointConventionBuilder>)MapPut }, 54new object[] { (Func<IEndpointRouteBuilder, string, RequestDelegate, IEndpointConventionBuilder>)MapDelete }, 55new object[] { (Func<IEndpointRouteBuilder, string, RequestDelegate, IEndpointConventionBuilder>)Map }, 80public async Task MapEndpoint_ReturnGenericTypeTask_GeneratedDelegate(Func<IEndpointRouteBuilder, string, RequestDelegate, IEndpointConventionBuilder> map) 112public async Task MapEndpoint_CanBeFiltered_EndpointFilterFactory(Func<IEndpointRouteBuilder, string, RequestDelegate, IEndpointConventionBuilder> map) 327public void MapEndpoint_UsesOriginalRequestDelegateInstance_IfFilterDoesNotChangePerRequestBehavior(Func<IEndpointRouteBuilder, string, RequestDelegate, IEndpointConventionBuilder> map) 431public void Map_EndpointMetadataNotDuplicated(Func<IEndpointRouteBuilder, string, RequestDelegate, IEndpointConventionBuilder> map) 454public void AddingMetadataAfterBuildingEndpointThrows(Func<IEndpointRouteBuilder, string, RequestDelegate, IEndpointConventionBuilder> map)
Builder\RouteHandlerEndpointRouteBuilderExtensionsTest.cs (10)
54new object?[] { (Func<IEndpointRouteBuilder, string, Delegate, IEndpointConventionBuilder>)MapGet, "GET" }, 55new object?[] { (Func<IEndpointRouteBuilder, string, Delegate, IEndpointConventionBuilder>)MapPost, "POST" }, 56new object?[] { (Func<IEndpointRouteBuilder, string, Delegate, IEndpointConventionBuilder>)MapPut, "PUT" }, 57new object?[] { (Func<IEndpointRouteBuilder, string, Delegate, IEndpointConventionBuilder>)MapDelete, "DELETE" }, 58new object?[] { (Func<IEndpointRouteBuilder, string, Delegate, IEndpointConventionBuilder>)MapPatch, "PATCH" }, 59new object?[] { (Func<IEndpointRouteBuilder, string, Delegate, IEndpointConventionBuilder>)Map, null }, 450public void MapVerbDoesNotDuplicateMetadata(Func<IEndpointRouteBuilder, string, Delegate, IEndpointConventionBuilder> map, string expectedMethod) 481public void AddingMetadataAfterBuildingEndpointThrows(Func<IEndpointRouteBuilder, string, Delegate, IEndpointConventionBuilder> map, string expectedMethod) 505public async Task MapVerbWithExplicitRouteParameterIsCaseInsensitive(Func<IEndpointRouteBuilder, string, Delegate, IEndpointConventionBuilder> map, string expectedMethod) 547public async Task MapVerbWithRouteParameterDoesNotFallbackToQuery(Func<IEndpointRouteBuilder, string, Delegate, IEndpointConventionBuilder> map, string expectedMethod)
Microsoft.AspNetCore.Server.Kestrel.Core (2)
HttpsConnectionAdapterOptions.cs (1)
72public Func<X509Certificate2, X509Chain?, SslPolicyErrors, bool>? ClientCertificateValidation { get; set; }
Middleware\HttpsConnectionMiddleware.cs (1)
377Func<X509Certificate2, X509Chain?, SslPolicyErrors, bool>? clientCertificateValidation,
Microsoft.AspNetCore.Server.Kestrel.Microbenchmarks (1)
SchedulerBenchmark.cs (1)
30private Func<int, ParallelLoopState, PipeScheduler[], PipeScheduler[]> _parallelAction;
Microsoft.AspNetCore.SignalR.Client.Core (3)
HubConnectionExtensions.cs (1)
279public static IDisposable On<T1, T2, T3>(this HubConnection hubConnection, string methodName, Func<T1, T2, T3, Task> handler)
HubConnectionExtensions.OnResult.cs (2)
129public static IDisposable On<T1, T2, T3, TResult>(this HubConnection hubConnection, string methodName, Func<T1, T2, T3, TResult> handler) 309public static IDisposable On<T1, T2, T3, TResult>(this HubConnection hubConnection, string methodName, Func<T1, T2, T3, Task<TResult>> handler)
Microsoft.AspNetCore.SignalR.Client.Tests (1)
TestHttpMessageHandler.cs (1)
135public void OnRequest(Func<HttpRequestMessage, Func<Task<HttpResponseMessage>>, CancellationToken, Task<HttpResponseMessage>> handler)
Microsoft.Build (1)
Evaluation\LazyItemEvaluator.LazyItemOperation.cs (1)
148private string RouteCall(string itemType, string name, Func<IMetadataTable, string, string, string> getEscapedValueFunc)
Microsoft.Build.Engine.UnitTests (7)
Evaluation\Expander_Tests.cs (1)
2879Func<string, string, string, string> formatString = (aString, platform, architecture) => aString
InternalEngineHelpers.cs (2)
42private readonly Func<SdkReference, SdkResolverContext, SdkResultFactory, Framework.SdkResult> _resolveFunc; 56public ConfigurableMockSdkResolver(Func<SdkReference, SdkResolverContext, SdkResultFactory, Framework.SdkResult> resolveFunc)
ProjectCache\ProjectCacheTests.cs (4)
196private readonly Func<BuildRequestData, PluginLoggerBase, CancellationToken, Task<CacheResult>> _getCacheResultDelegate; 198public DelegatingMockCache(Func<BuildRequestData, PluginLoggerBase, CancellationToken, Task<CacheResult>> getCacheResultDelegate) 236public Func<CacheContext, PluginLoggerBase, CancellationToken, Task>? BeginBuildImplementation { get; set; } 237public Func<BuildRequestData, PluginLoggerBase, CancellationToken, Task<CacheResult>>? GetCacheResultImplementation { get; set; }
Microsoft.Build.Tasks.Core (1)
Copy.cs (1)
393private void TryCopyViaLink(string linkComment, MessageImportance messageImportance, FileState sourceFileState, FileState destinationFileState, out bool linkCreated, ref string errorMessage, Func<string, string, string, bool> createLink)
Microsoft.CodeAnalysis (25)
Collections\ArrayBuilderExtensions.cs (2)
151public static ImmutableArray<TResult> SelectAsArrayWithIndex<TItem, TArg, TResult>(this ArrayBuilder<TItem> items, Func<TItem, int, TArg, TResult> map, TArg arg) 275public static void RemoveWhere<TItem, TArg>(this ArrayBuilder<TItem> builder, Func<TItem, int, TArg, bool> filter, TArg arg)
Collections\ImmutableArrayExtensions.cs (4)
171public static ImmutableArray<TResult> SelectAsArray<TItem, TArg, TResult>(this ImmutableArray<TItem> items, Func<TItem, int, TArg, TResult> map, TArg arg) 439public static async ValueTask<ImmutableArray<TResult>> SelectAsArrayAsync<TItem, TArg, TResult>(this ImmutableArray<TItem> array, Func<TItem, TArg, CancellationToken, ValueTask<TResult>> selector, TArg arg, CancellationToken cancellationToken) 454public static ValueTask<ImmutableArray<TResult>> SelectManyAsArrayAsync<TItem, TArg, TResult>(this ImmutableArray<TItem> source, Func<TItem, TArg, CancellationToken, ValueTask<ImmutableArray<TResult>>> selector, TArg arg, CancellationToken cancellationToken) 1266internal static bool SequenceEqual<TElement, TArg>(this ImmutableArray<TElement> array1, ImmutableArray<TElement> array2, TArg arg, Func<TElement, TElement, TArg, bool> predicate)
DiagnosticAnalyzer\AnalyzerExecutor.cs (3)
45private readonly Func<SyntaxTree, TextSpan, CancellationToken, bool> _isGeneratedCodeLocation; 108Func<SyntaxTree, TextSpan, CancellationToken, bool> isGeneratedCodeLocation, 140Func<SyntaxTree, TextSpan, CancellationToken, bool> isGeneratedCodeLocation,
DiagnosticAnalyzer\AnalyzerManager.AnalyzerExecutionContext.cs (1)
257Func<DiagnosticAnalyzer, AnalyzerExecutor, CancellationToken, ImmutableArray<TDescriptor>> computeDescriptorsNoLock,
InternalUtilities\ConcurrentDictionaryExtensions.cs (1)
48Func<TKey, TValue, TArg, TValue> updateValueFactory,
InternalUtilities\EnumerableExtensions.cs (2)
511public static async ValueTask<ImmutableArray<TResult>> SelectAsArrayAsync<TItem, TArg, TResult>(this IEnumerable<TItem> source, Func<TItem, TArg, CancellationToken, ValueTask<TResult>> selector, TArg arg, CancellationToken cancellationToken) 523public static async ValueTask<ImmutableArray<TResult>> SelectManyAsArrayAsync<TItem, TArg, TResult>(this IEnumerable<TItem> source, Func<TItem, TArg, CancellationToken, ValueTask<IEnumerable<TResult>>> selector, TArg arg, CancellationToken cancellationToken)
MetadataReader\PEModule.cs (1)
1418Func<string, TypedConstant, bool, (bool IsCallConvs, ImmutableHashSet<INamedTypeSymbolInternal>? CallConvs)> unmanagedCallersOnlyDecoder)
MetadataReference\AssemblyIdentityMap.cs (1)
76public bool TryGetValue(AssemblyIdentity identity, out TValue value, Func<Version, Version, TValue, bool> comparer)
Operations\ControlFlowGraphBuilder.cs (2)
1997private ImmutableArray<T> PopArray<T>(ImmutableArray<T> originalArray, Func<IOperation, int, ImmutableArray<T>, T>? wrapper = null) where T : IOperation 2019private ImmutableArray<T> VisitArray<T>(ImmutableArray<T> originalArray, Func<T, IOperation>? unwrapper = null, Func<IOperation, int, ImmutableArray<T>, T>? wrapper = null) where T : IOperation
src\Dependencies\PooledObjects\PooledDelegates.cs (8)
279public static Releaser GetPooledFunction<T1, T2, TArg, TResult>(Func<T1, T2, TArg, TResult> unboundFunction, TArg argument, out Func<T1, T2, TResult> boundFunction) 280=> GetPooledDelegate<FuncWithBoundArgument<T1, T2, TArg, TResult>, TArg, Func<T1, T2, TArg, TResult>, Func<T1, T2, TResult>>(unboundFunction, argument, out boundFunction); 283/// Gets a <see cref="Func{T1, T2, T3, TResult}"/> delegate, which calls <paramref name="unboundFunction"/> with the 315public static Releaser GetPooledFunction<T1, T2, T3, TArg, TResult>(Func<T1, T2, T3, TArg, TResult> unboundFunction, TArg argument, out Func<T1, T2, T3, TResult> boundFunction) 316=> GetPooledDelegate<FuncWithBoundArgument<T1, T2, T3, TArg, TResult>, TArg, Func<T1, T2, T3, TArg, TResult>, Func<T1, T2, T3, TResult>>(unboundFunction, argument, out boundFunction); 437: AbstractDelegateWithBoundArgument<FuncWithBoundArgument<T1, T2, TArg, TResult>, TArg, Func<T1, T2, TArg, TResult>, Func<T1, T2, TResult>> 444: AbstractDelegateWithBoundArgument<FuncWithBoundArgument<T1, T2, T3, TArg, TResult>, TArg, Func<T1, T2, T3, TArg, TResult>, Func<T1, T2, T3, TResult>> 446protected override Func<T1, T2, T3, TResult> Bind()
Microsoft.CodeAnalysis.CodeStyle (53)
src\Compilers\Core\Portable\Collections\ArrayBuilderExtensions.cs (2)
151public static ImmutableArray<TResult> SelectAsArrayWithIndex<TItem, TArg, TResult>(this ArrayBuilder<TItem> items, Func<TItem, int, TArg, TResult> map, TArg arg) 275public static void RemoveWhere<TItem, TArg>(this ArrayBuilder<TItem> builder, Func<TItem, int, TArg, bool> filter, TArg arg)
src\Compilers\Core\Portable\Collections\ImmutableArrayExtensions.cs (4)
171public static ImmutableArray<TResult> SelectAsArray<TItem, TArg, TResult>(this ImmutableArray<TItem> items, Func<TItem, int, TArg, TResult> map, TArg arg) 439public static async ValueTask<ImmutableArray<TResult>> SelectAsArrayAsync<TItem, TArg, TResult>(this ImmutableArray<TItem> array, Func<TItem, TArg, CancellationToken, ValueTask<TResult>> selector, TArg arg, CancellationToken cancellationToken) 454public static ValueTask<ImmutableArray<TResult>> SelectManyAsArrayAsync<TItem, TArg, TResult>(this ImmutableArray<TItem> source, Func<TItem, TArg, CancellationToken, ValueTask<ImmutableArray<TResult>>> selector, TArg arg, CancellationToken cancellationToken) 1266internal static bool SequenceEqual<TElement, TArg>(this ImmutableArray<TElement> array1, ImmutableArray<TElement> array2, TArg arg, Func<TElement, TElement, TArg, bool> predicate)
src\Compilers\Core\Portable\InternalUtilities\ConcurrentDictionaryExtensions.cs (1)
48Func<TKey, TValue, TArg, TValue> updateValueFactory,
src\Compilers\Core\Portable\InternalUtilities\EnumerableExtensions.cs (2)
511public static async ValueTask<ImmutableArray<TResult>> SelectAsArrayAsync<TItem, TArg, TResult>(this IEnumerable<TItem> source, Func<TItem, TArg, CancellationToken, ValueTask<TResult>> selector, TArg arg, CancellationToken cancellationToken) 523public static async ValueTask<ImmutableArray<TResult>> SelectManyAsArrayAsync<TItem, TArg, TResult>(this IEnumerable<TItem> source, Func<TItem, TArg, CancellationToken, ValueTask<IEnumerable<TResult>>> selector, TArg arg, CancellationToken cancellationToken)
src\Dependencies\PooledObjects\PooledDelegates.cs (8)
279public static Releaser GetPooledFunction<T1, T2, TArg, TResult>(Func<T1, T2, TArg, TResult> unboundFunction, TArg argument, out Func<T1, T2, TResult> boundFunction) 280=> GetPooledDelegate<FuncWithBoundArgument<T1, T2, TArg, TResult>, TArg, Func<T1, T2, TArg, TResult>, Func<T1, T2, TResult>>(unboundFunction, argument, out boundFunction); 283/// Gets a <see cref="Func{T1, T2, T3, TResult}"/> delegate, which calls <paramref name="unboundFunction"/> with the 315public static Releaser GetPooledFunction<T1, T2, T3, TArg, TResult>(Func<T1, T2, T3, TArg, TResult> unboundFunction, TArg argument, out Func<T1, T2, T3, TResult> boundFunction) 316=> GetPooledDelegate<FuncWithBoundArgument<T1, T2, T3, TArg, TResult>, TArg, Func<T1, T2, T3, TArg, TResult>, Func<T1, T2, T3, TResult>>(unboundFunction, argument, out boundFunction); 437: AbstractDelegateWithBoundArgument<FuncWithBoundArgument<T1, T2, TArg, TResult>, TArg, Func<T1, T2, TArg, TResult>, Func<T1, T2, TResult>> 444: AbstractDelegateWithBoundArgument<FuncWithBoundArgument<T1, T2, T3, TArg, TResult>, TArg, Func<T1, T2, T3, TArg, TResult>, Func<T1, T2, T3, TResult>> 446protected override Func<T1, T2, T3, TResult> Bind()
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Extensions\SyntaxNodeExtensions.cs (6)
342Func<SyntaxNode, SyntaxNode, CancellationToken, Task<SyntaxNode>> computeReplacementAsync, 364Func<SyntaxToken, SyntaxToken, CancellationToken, Task<SyntaxToken>> computeReplacementAsync, 377Func<SyntaxTrivia, SyntaxTrivia, CancellationToken, Task<SyntaxTrivia>> computeReplacementAsync, 390Func<SyntaxNode, SyntaxNode, CancellationToken, Task<SyntaxNode>>? computeReplacementNodeAsync, 392Func<SyntaxToken, SyntaxToken, CancellationToken, Task<SyntaxToken>>? computeReplacementTokenAsync, 394Func<SyntaxTrivia, SyntaxTrivia, CancellationToken, Task<SyntaxTrivia>>? computeReplacementTriviaAsync,
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Formatting\Context\FormattingContext.cs (1)
196Func<FormattingContext, IndentBlockOperation, SyntaxToken, int> relativeIndentationDeltaGetter = static (self, operation, effectiveBaseToken) =>
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Formatting\Context\FormattingContext.IndentationData.cs (3)
44private readonly Func<FormattingContext, IndentBlockOperation, SyntaxToken, int> _indentationDeltaGetter; 56public RelativeIndentationData(FormattingContext formattingContext, int inseparableRegionSpanStart, TextSpan textSpan, IndentBlockOperation operation, Func<FormattingContext, IndentBlockOperation, SyntaxToken> effectiveBaseTokenGetter, Func<FormattingContext, IndentBlockOperation, SyntaxToken, int> indentationDeltaGetter, Func<FormattingContext, SyntaxToken, int> baseIndentationGetter) 70private RelativeIndentationData(FormattingContext formattingContext, int inseparableRegionSpanStart, TextSpan textSpan, IndentBlockOperation operation, Func<FormattingContext, IndentBlockOperation, SyntaxToken> effectiveBaseTokenGetter, Func<FormattingContext, IndentBlockOperation, SyntaxToken, int> indentationDeltaGetter, Func<FormattingContext, SyntaxToken, int> baseIndentationGetter, int lazyIndentationDelta)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Formatting\ContextMutableIntervalTree.cs (4)
21private readonly Func<T, int, int, bool> _edgeExclusivePredicate; 22private readonly Func<T, int, int, bool> _edgeInclusivePredicate; 23private readonly Func<T, int, int, bool> _containPredicate; 66private T? GetSmallestContainingIntervalWorker(int start, int length, Func<T, int, int, bool> predicate)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Log\Logger.cs (2)
114public static void Log<TArg0, TArg1, TArg2>(FunctionId functionId, Func<TArg0, TArg1, TArg2, string> messageGetter, TArg0 arg0, TArg1 arg1, TArg2 arg2, LogLevel logLevel = LogLevel.Debug) 201public static IDisposable LogBlock<TArg0, TArg1, TArg2>(FunctionId functionId, Func<TArg0, TArg1, TArg2, string> messageGetter, TArg0 arg0, TArg1 arg1, TArg2 arg2, CancellationToken token, LogLevel logLevel = LogLevel.Trace)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Log\LogMessage.cs (3)
29public static LogMessage Create<TArg0, TArg1, TArg2>(Func<TArg0, TArg1, TArg2, string> messageGetter, TArg0 arg0, TArg1 arg1, TArg2 arg2, LogLevel logLevel) 190private Func<TArg0, TArg1, TArg2, string>? _messageGetter; 195public static LogMessage Construct(Func<TArg0, TArg1, TArg2, string> messageGetter, TArg0 arg0, TArg1 arg1, TArg2 arg2, LogLevel logLevel)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Serialization\ObjectReader.cs (1)
263Func<BinaryReader, T[], int, int> read,
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Utilities\IDictionaryExtensions.cs (1)
232public static void RemoveAll<TKey, TValue, TArg>(this Dictionary<TKey, TValue> dictionary, Func<TKey, TValue, TArg, bool> predicate, TArg arg)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Utilities\ProducerConsumer.cs (15)
43Func<ImmutableArray<TItem>, TArgs, CancellationToken, Task> consumeItems, 66Func<Action<TItem>, TArgs, CancellationToken, Task> produceItems, 67Func<ImmutableArray<TItem>, TArgs, CancellationToken, Task> consumeItems, 84Func<Action<TItem>, TArgs, CancellationToken, Task> produceItems, 85Func<IAsyncEnumerable<TItem>, TArgs, CancellationToken, Task> consumeItems, 108Func<IAsyncEnumerable<TItem>, TArgs, CancellationToken, Task> consumeItems, 122Func<IAsyncEnumerable<TItem>, TArgs, CancellationToken, Task> consumeItems, 145Func<ImmutableArray<TItem>, TArgs, CancellationToken, Task> consumeItems, 159Func<ImmutableArray<TItem>, TArgs, CancellationToken, Task> consumeItems, 178Func<IAsyncEnumerable<TItem>, TArgs, CancellationToken, Task<TResult>> consumeItems, 192Func<IAsyncEnumerable<TItem>, TArgs, CancellationToken, Task<TResult>> consumeItems, 244Func<ChannelReader<TItem>, TArgs, CancellationToken, Task<TResult>> consumeItems, 267Func<Action<TItem>, TArgs, CancellationToken, Task> produceItems, 301Func<Action<TItem>, TArgs, CancellationToken, Task> produceItems, 302Func<ChannelReader<TItem>, TArgs, CancellationToken, Task<TResult>> consumeItems,
Microsoft.CodeAnalysis.CodeStyle.Fixes (6)
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Extensions\SyntaxEditorExtensions.cs (6)
30Func<SemanticModel, TType, TNode, bool> canReplace, 53Func<SemanticModel, TType, TNode, bool> canReplace, 76Func<SemanticModel, SyntaxNode, TNode, SyntaxNode> updateRoot, 97Func<SemanticModel, TType, TNode, bool> canReplace, 120Func<SemanticModel, SyntaxNode, TNode, SyntaxNode> updateRoot, 155Func<SemanticModel, TType, TNode, bool> canReplace,
Microsoft.CodeAnalysis.CSharp (22)
Binder\Binder_InterpolatedString.cs (1)
519Func<BoundUnconvertedInterpolatedString, int, (ImmutableArray<ImmutableArray<BoundExpression>>, TypeSymbol), BoundExpression> interpolationFactory =
BoundTree\BoundNodeExtensions.cs (2)
185Func<TInterpolatedStringType, int, TArg, TResult> interpolatedStringFactory, 198Func<TInterpolatedStringType, int, TArg, TResult> interpolatedStringFactory,
Compilation\CSharpCompilation.cs (1)
3219private ReadOnlyBindingDiagnostic<AssemblySymbol> GetSourceDeclarationDiagnostics(SyntaxTree? syntaxTree = null, TextSpan? filterSpanWithinTree = null, Func<IEnumerable<Diagnostic>, SyntaxTree, TextSpan?, IEnumerable<Diagnostic>>? locationFilterOpt = null, Predicate<Symbol>? symbolFilter = null, CancellationToken cancellationToken = default)
Emitter\Model\PEAssemblyBuilder.cs (2)
389var createParameterlessEmbeddedAttributeSymbol = new Func<string, NamespaceSymbol, BindingDiagnosticBag, SynthesizedEmbeddedAttributeSymbol>(CreateParameterlessEmbeddedAttributeSymbol); 558Func<string, NamespaceSymbol, BindingDiagnosticBag, T> factory,
Lowering\LocalRewriter\DelegateCacheRewriter.cs (1)
235private static readonly Func<TypeSymbol, HashSet<TypeParameterSymbol>, bool, bool> s_typeParameterSymbolCollector = (typeSymbol, result, _) =>
Operations\CSharpOperationFactory.cs (1)
1539Func<BoundInterpolatedString, int, (CSharpOperationFactory, InterpolatedStringHandlerData), IOperation> createInterpolatedString
Symbols\Compilation_WellKnownMembers.cs (1)
996Func<TypeSymbol, (ArrayBuilder<bool>, bool), bool, bool> visitor =
Symbols\ConstraintsHelper.cs (1)
583private static readonly Func<TypeSymbol, CheckConstraintsArgsBoxed, bool, bool> s_checkConstraintsSingleTypeFunc = (type, arg, unused) => CheckConstraintsSingleType(type, in arg.Args);
Symbols\NativeIntegerTypeSymbol.cs (1)
464Func<NativeIntegerTypeSymbol, NativeIntegerPropertySymbol, MethodSymbol?, NativeIntegerMethodSymbol?> getAccessor) :
Symbols\SymbolExtensions.cs (1)
233private static readonly Func<TypeSymbol, Symbol, bool, bool> s_hasInvalidTypeParameterFunc =
Symbols\TypeSymbolExtensions.cs (10)
723Func<TypeSymbol, T, bool, bool> predicate, 752Func<TypeWithAnnotations, T, bool, bool>? typeWithAnnotationsPredicate, 753Func<TypeSymbol, T, bool, bool>? typePredicate, 953static TypeSymbol? visitFunctionPointerType(FunctionPointerTypeSymbol type, Func<TypeWithAnnotations, T, bool, bool>? typeWithAnnotationsPredicate, Func<TypeSymbol, T, bool, bool>? typePredicate, T arg, bool useDefaultType, bool canDigThroughNullable, bool visitCustomModifiers, out TypeWithAnnotations next) 1204private static readonly Func<TypeSymbol, TypeParameterSymbol?, bool, bool> s_containsTypeParameterPredicate = 1215private static readonly Func<TypeSymbol, Symbol, bool, bool> s_isTypeParameterWithSpecificContainerPredicate = 1224private static readonly Func<TypeSymbol, HashSet<TypeParameterSymbol>, bool, bool> s_containsTypeParametersPredicate = 1233private static readonly Func<TypeSymbol, object?, bool, bool> s_containsMethodTypeParameterPredicate = 1245private static readonly Func<TypeSymbol, object?, bool, bool> s_containsDynamicPredicate = (type, unused1, unused2) => type.TypeKind == TypeKind.Dynamic;
Microsoft.CodeAnalysis.CSharp.CodeStyle.Fixes (1)
src\Analyzers\CSharp\CodeFixes\MakeLocalFunctionStatic\PassInCapturedVariablesAsArgumentsCodeFixProvider.cs (1)
65Func<Document, LocalFunctionStatementSyntax, ImmutableArray<ISymbol>, Task> fixer,
Microsoft.CodeAnalysis.CSharp.EditorFeatures.UnitTests (1)
Debugging\ProximityExpressionsGetterTests.cs (1)
69Func<CSharpProximityExpressionsService, Document, int, Task> continuation)
Microsoft.CodeAnalysis.CSharp.Emit2.UnitTests (2)
Emit\NumericIntPtrTests.cs (2)
8897void unaryOperator(string opType, string op, string operand, string expectedResult, Func<string, string, string, DiagnosticDescription[]> getDiagnostics = null) 8951void binaryOperator(string opType, string op, string leftType, string leftOperand, string rightType, string rightOperand, string expectedResult, Func<string, string, string, DiagnosticDescription[]> getDiagnostics = null)
Microsoft.CodeAnalysis.CSharp.Emit3.UnitTests (1)
FlowAnalysis\FlowTestBase.cs (1)
211protected T CompileAndGetModelAndStatements<T>(string program, Func<SemanticModel, StatementSyntax, StatementSyntax, T> analysisDelegate)
Microsoft.CodeAnalysis.CSharp.Features (6)
CodeRefactorings\EnableNullable\EnableNullableCodeRefactoringProvider.cs (2)
266Func<CodeActionPurpose, IProgress<CodeAnalysisProgress>, CancellationToken, Task<Solution>> createChangedSolution) 272private readonly Func<CodeActionPurpose, IProgress<CodeAnalysisProgress>, CancellationToken, Task<Solution>> _createChangedSolution = createChangedSolution;
CodeRefactorings\EnableNullable\EnableNullableCodeRefactoringProvider.FixAllProvider.cs (2)
56private sealed class FixAllCodeAction(Func<CodeActionPurpose, IProgress<CodeAnalysisProgress>, CancellationToken, Task<Solution>> createChangedSolution) 62private readonly Func<CodeActionPurpose, IProgress<CodeAnalysisProgress>, CancellationToken, Task<Solution>> _createChangedSolution = createChangedSolution;
ConvertBetweenRegularAndVerbatimString\AbstractConvertBetweenRegularAndVerbatimStringCodeRefactoringProvider.cs (1)
82Func<IVirtualCharService, StringBuilder, TStringExpressionSyntax, TStringExpressionSyntax> convert,
src\Analyzers\CSharp\CodeFixes\MakeLocalFunctionStatic\PassInCapturedVariablesAsArgumentsCodeFixProvider.cs (1)
65Func<Document, LocalFunctionStatementSyntax, ImmutableArray<ISymbol>, Task> fixer,
Microsoft.CodeAnalysis.CSharp.Features.UnitTests (1)
Copilot\CSharpImplementNotImplementedExceptionFixProviderTests.cs (1)
644public Func<Document, ImmutableDictionary<SyntaxNode, ImmutableArray<ReferencedSymbol>>, CancellationToken, ImmutableDictionary<SyntaxNode, ImplementationDetails>>? SetupFixAll { get; internal set; }
Microsoft.CodeAnalysis.CSharp.Scripting (2)
Hosting\CommandLine\Csi.cs (2)
18private readonly Func<string, PEStreamOptions, MetadataReferenceProperties, MetadataImageReference> _createFromFileFunc; 25Func<string, PEStreamOptions, MetadataReferenceProperties, MetadataImageReference>? createFromFileFunc = null)
Microsoft.CodeAnalysis.CSharp.Semantic.UnitTests (2)
Semantics\NativeIntegerTests.cs (2)
13148void unaryOperator(string opType, string op, string operand, string expectedResult, Func<string, string, string, DiagnosticDescription[]> getDiagnostics = null) 13202void binaryOperator(string opType, string op, string leftType, string leftOperand, string rightType, string rightOperand, string expectedResult, Func<string, string, string, DiagnosticDescription[]> getDiagnostics = null)
Microsoft.CodeAnalysis.CSharp.Symbol.UnitTests (1)
Compilation\SemanticModelGetDeclaredSymbolAPITests.cs (1)
2186Func<int, string, bool, ImmutableArray<ISymbol>> lookupAttributeType = (pos, name, isVerbatim) =>
Microsoft.CodeAnalysis.EditorFeatures (5)
Classification\CopyPasteAndPrintingClassificationBufferTaggerProvider.Tagger.cs (1)
180Func<NormalizedSnapshotSpanCollection, SegmentedList<TagSpan<IClassificationTag>>, VoidResult, Task> GetTaggingFunction(
Classification\TotalClassificationTaggerProvider.cs (3)
102Func<NormalizedSnapshotSpanCollection, SegmentedList<TagSpan<IClassificationTag>>, TArg, Task> addSyntacticSpansAsync, 103Func<NormalizedSnapshotSpanCollection, SegmentedList<TagSpan<IClassificationTag>>, TArg, Task> addSemanticSpansAsync, 104Func<NormalizedSnapshotSpanCollection, SegmentedList<TagSpan<IClassificationTag>>, TArg, Task> addEmbeddedSpansAsync,
Tagging\AbstractAsynchronousTaggerProvider.TagSource_ProduceTags.cs (1)
243Func<ImmutableDictionary<ITextBuffer, TagSpanIntervalTree<TTag>>, TArgs, CancellationToken, ValueTask<(ImmutableDictionary<ITextBuffer, TagSpanIntervalTree<TTag>> newTagTrees, TResult result)>> callback,
Microsoft.CodeAnalysis.EditorFeatures.UnitTests (1)
Diagnostics\DiagnosticAnalyzerServiceTests.cs (1)
216Func<bool, bool, ImmutableArray<DiagnosticData>, (bool, bool)> resultSetter,
Microsoft.CodeAnalysis.EditorFeatures.Wpf (4)
Lightup\ISmartRenameSessionWrapper.cs (1)
38private static readonly Func<object, object, CancellationToken, Task<IReadOnlyList<string>>>? s_getSuggestionsAsync_WithContext;
Lightup\LightupHelpers.cs (3)
434public static Func<T, TArg0, TArg1, TResult> CreateFunctionAccessor<T, TArg0, TArg1, TResult>(Type? type, string methodName, Type? arg0Type, Type? arg1Type, TResult defaultValue) 489Expression.Lambda<Func<T, TArg0, TArg1, TResult>>( 587private static Func<T, TArg0, TArg1, TResult> CreateFallbackFunction<T, TArg0, TArg1, TResult>(TResult defaultValue)
Microsoft.CodeAnalysis.ExternalAccess.FSharp (1)
Completion\IFSharpCommonCompletionProvider.cs (1)
22Func<CompletionItem, char?, CancellationToken, Task<TextChange?>> baseGetTextChangeAsync,
Microsoft.CodeAnalysis.ExternalAccess.Razor.Features (8)
Remote\RazorRemoteHostClient.cs (4)
54public async ValueTask<bool> TryInvokeAsync<TService>(Func<TService, RazorRemoteServiceCallbackIdWrapper, CancellationToken, ValueTask> invocation, object callbackTarget, CancellationToken cancellationToken) where TService : class 60public async ValueTask<Optional<TResult>> TryInvokeAsync<TService, TResult>(Func<TService, RazorRemoteServiceCallbackIdWrapper, CancellationToken, ValueTask<TResult>> invocation, object callbackTarget, CancellationToken cancellationToken) where TService : class 68public async ValueTask<bool> TryInvokeAsync<TService>(Solution solution, Func<TService, RazorPinnedSolutionInfoWrapper, CancellationToken, ValueTask> invocation, CancellationToken cancellationToken) where TService : class 74public async ValueTask<Optional<TResult>> TryInvokeAsync<TService, TResult>(Solution solution, Func<TService, RazorPinnedSolutionInfoWrapper, CancellationToken, ValueTask<TResult>> invocation, CancellationToken cancellationToken) where TService : class
Remote\RazorRemoteServiceConnectionWrapper.cs (4)
33public ValueTask<bool> TryInvokeAsync(Func<TService, RazorRemoteServiceCallbackIdWrapper, CancellationToken, ValueTask> invocation, CancellationToken cancellationToken) 38public ValueTask<Optional<TResult>> TryInvokeAsync<TResult>(Func<TService, RazorRemoteServiceCallbackIdWrapper, CancellationToken, ValueTask<TResult>> invocation, CancellationToken cancellationToken) 45public ValueTask<bool> TryInvokeAsync(Solution solution, Func<TService, RazorPinnedSolutionInfoWrapper, CancellationToken, ValueTask> invocation, CancellationToken cancellationToken) 51public ValueTask<Optional<TResult>> TryInvokeAsync<TResult>(Solution solution, Func<TService, RazorPinnedSolutionInfoWrapper, CancellationToken, ValueTask<TResult>> invocation, CancellationToken cancellationToken)
Microsoft.CodeAnalysis.Features (16)
Extensions\ExtensionMessageHandlerService_RemoteOrLocal.cs (2)
21Func<ExtensionMessageHandlerService, TArg, CancellationToken, ValueTask> executeInProcessAsync, 46Func<ExtensionMessageHandlerService, TArg, CancellationToken, ValueTask<TResult>> executeInProcessAsync,
ExternalAccess\UnitTesting\SolutionCrawler\UnitTestingWorkCoordinator.UnitTestingIncrementalAnalyzerProcessor.cs (2)
29private static readonly Func<int, object, bool, string> s_enqueueLogger = EnqueueLogger; 151Func<IUnitTestingIncrementalAnalyzer, T, CancellationToken, Task> runnerAsync,
ExternalAccess\UnitTesting\SolutionCrawler\UnitTestingWorkCoordinator.UnitTestingSemanticChangeProcessor.cs (1)
31private static readonly Func<int, DocumentId, bool, string> s_enqueueLogger = (tick, documentId, hint) => $"Tick:{tick}, {documentId}, {documentId.ProjectId}, hint:{hint}";
NavigateTo\AbstractNavigateToSearchService.CachedDocumentSearch.cs (2)
77var onItemsFound = GetOnItemsFoundCallback(solution, activeDocument, onResultsFound); 105Func<ImmutableArray<RoslynNavigateToItem>, VoidResult, CancellationToken, Task> onItemsFound,
NavigateTo\AbstractNavigateToSearchService.cs (1)
36private static Func<ImmutableArray<RoslynNavigateToItem>, VoidResult, CancellationToken, Task> GetOnItemsFoundCallback(
NavigateTo\AbstractNavigateToSearchService.GeneratedDocumentSearch.cs (2)
36var onItemsFound = GetOnItemsFoundCallback(solution, activeDocument, onResultsFound); 64Func<ImmutableArray<RoslynNavigateToItem>, VoidResult, CancellationToken, Task> onItemsFound,
NavigateTo\AbstractNavigateToSearchService.NormalSearch.cs (4)
34var onItemsFound = GetOnItemsFoundCallback(solution, activeDocument: null, onResultsFound); 57Func<ImmutableArray<RoslynNavigateToItem>, VoidResult, CancellationToken, Task> onItemsFound, 162var onItemsFound = GetOnItemsFoundCallback(solution, activeDocument, onResultsFound); 191Func<ImmutableArray<RoslynNavigateToItem>, VoidResult, CancellationToken, Task> onItemsFound,
NavigateTo\IRemoteNavigateToSearchService.cs (1)
51Func<ImmutableArray<RoslynNavigateToItem>, VoidResult, CancellationToken, Task> onItemsFound,
ReplacePropertyWithMethods\AbstractReplacePropertyWithMethodsService.cs (1)
185private static readonly Func<SyntaxNode, SyntaxGenerator, ReplaceParentArgs, SyntaxNode> replaceParentCallback =
Microsoft.CodeAnalysis.Features.Test.Utilities (2)
EditAndContinue\MockEditAndContinueService.cs (1)
26public Func<Solution, IImmutableSet<ProjectId>, ActiveStatementSpanProvider, EmitSolutionUpdateResults>? EmitSolutionUpdateImpl;
EditAndContinue\MockPdbMatchingSourceTextProvider.cs (1)
16public Func<string, ImmutableArray<byte>, SourceHashAlgorithm, string?>? TryGetMatchingSourceTextImpl { get; set; }
Microsoft.CodeAnalysis.InteractiveHost (2)
src\Compilers\Core\Portable\Collections\ArrayBuilderExtensions.cs (2)
151public static ImmutableArray<TResult> SelectAsArrayWithIndex<TItem, TArg, TResult>(this ArrayBuilder<TItem> items, Func<TItem, int, TArg, TResult> map, TArg arg) 275public static void RemoveWhere<TItem, TArg>(this ArrayBuilder<TItem> builder, Func<TItem, int, TArg, bool> filter, TArg arg)
Microsoft.CodeAnalysis.PooledObjects.Package (8)
PooledDelegates.cs (8)
279public static Releaser GetPooledFunction<T1, T2, TArg, TResult>(Func<T1, T2, TArg, TResult> unboundFunction, TArg argument, out Func<T1, T2, TResult> boundFunction) 280=> GetPooledDelegate<FuncWithBoundArgument<T1, T2, TArg, TResult>, TArg, Func<T1, T2, TArg, TResult>, Func<T1, T2, TResult>>(unboundFunction, argument, out boundFunction); 283/// Gets a <see cref="Func{T1, T2, T3, TResult}"/> delegate, which calls <paramref name="unboundFunction"/> with the 315public static Releaser GetPooledFunction<T1, T2, T3, TArg, TResult>(Func<T1, T2, T3, TArg, TResult> unboundFunction, TArg argument, out Func<T1, T2, T3, TResult> boundFunction) 316=> GetPooledDelegate<FuncWithBoundArgument<T1, T2, T3, TArg, TResult>, TArg, Func<T1, T2, T3, TArg, TResult>, Func<T1, T2, T3, TResult>>(unboundFunction, argument, out boundFunction); 437: AbstractDelegateWithBoundArgument<FuncWithBoundArgument<T1, T2, TArg, TResult>, TArg, Func<T1, T2, TArg, TResult>, Func<T1, T2, TResult>> 444: AbstractDelegateWithBoundArgument<FuncWithBoundArgument<T1, T2, T3, TArg, TResult>, TArg, Func<T1, T2, T3, TArg, TResult>, Func<T1, T2, T3, TResult>> 446protected override Func<T1, T2, T3, TResult> Bind()
Microsoft.CodeAnalysis.Remote.ServiceHub (2)
Services\DiagnosticAnalyzer\PerformanceTrackerService.cs (1)
37private static readonly Func<IEnumerable<AnalyzerPerformanceInfo>, int, bool, string> s_snapshotLogger = SnapshotLogger;
Services\NavigateToSearch\RemoteNavigateToSearchService.cs (1)
31private (Func<ImmutableArray<RoslynNavigateToItem>, VoidResult, CancellationToken, Task> onItemsFound, Func<Task> onProjectCompleted) GetCallbacks(
Microsoft.CodeAnalysis.Remote.Workspaces (25)
BrokeredServiceConnection.cs (6)
129public override async ValueTask<bool> TryInvokeAsync(Func<TService, RemoteServiceCallbackId, CancellationToken, ValueTask> invocation, CancellationToken cancellationToken) 146public override async ValueTask<Optional<TResult>> TryInvokeAsync<TResult>(Func<TService, RemoteServiceCallbackId, CancellationToken, ValueTask<TResult>> invocation, CancellationToken cancellationToken) 164public override async ValueTask<bool> TryInvokeAsync(SolutionCompilationState compilationState, Func<TService, Checksum, CancellationToken, ValueTask> invocation, CancellationToken cancellationToken) 180public override async ValueTask<Optional<TResult>> TryInvokeAsync<TResult>(SolutionCompilationState compilationState, Func<TService, Checksum, CancellationToken, ValueTask<TResult>> invocation, CancellationToken cancellationToken) 197public override async ValueTask<bool> TryInvokeAsync(SolutionCompilationState compilationState, ProjectId projectId, Func<TService, Checksum, CancellationToken, ValueTask> invocation, CancellationToken cancellationToken) 213public override async ValueTask<Optional<TResult>> TryInvokeAsync<TResult>(SolutionCompilationState compilationState, ProjectId projectId, Func<TService, Checksum, CancellationToken, ValueTask<TResult>> invocation, CancellationToken cancellationToken)
ExternalAccess\Pythia\Api\PythiaRemoteHostClient.cs (4)
54public async ValueTask<bool> TryInvokeAsync<TService>(Func<TService, PythiaRemoteServiceCallbackIdWrapper, CancellationToken, ValueTask> invocation, object callbackTarget, CancellationToken cancellationToken) where TService : class 60public async ValueTask<Optional<TResult>> TryInvokeAsync<TService, TResult>(Func<TService, PythiaRemoteServiceCallbackIdWrapper, CancellationToken, ValueTask<TResult>> invocation, object callbackTarget, CancellationToken cancellationToken) where TService : class 68public async ValueTask<bool> TryInvokeAsync<TService>(Solution solution, Func<TService, PythiaPinnedSolutionInfoWrapper, CancellationToken, ValueTask> invocation, CancellationToken cancellationToken) where TService : class 74public async ValueTask<Optional<TResult>> TryInvokeAsync<TService, TResult>(Solution solution, Func<TService, PythiaPinnedSolutionInfoWrapper, CancellationToken, ValueTask<TResult>> invocation, CancellationToken cancellationToken) where TService : class
ExternalAccess\Pythia\Api\PythiaRemoteServiceConnectionWrapper.cs (4)
33public ValueTask<bool> TryInvokeAsync(Func<TService, PythiaRemoteServiceCallbackIdWrapper, CancellationToken, ValueTask> invocation, CancellationToken cancellationToken) 38public ValueTask<Optional<TResult>> TryInvokeAsync<TResult>(Func<TService, PythiaRemoteServiceCallbackIdWrapper, CancellationToken, ValueTask<TResult>> invocation, CancellationToken cancellationToken) 45public ValueTask<bool> TryInvokeAsync(Solution solution, Func<TService, PythiaPinnedSolutionInfoWrapper, CancellationToken, ValueTask> invocation, CancellationToken cancellationToken) 51public ValueTask<Optional<TResult>> TryInvokeAsync<TResult>(Solution solution, Func<TService, PythiaPinnedSolutionInfoWrapper, CancellationToken, ValueTask<TResult>> invocation, CancellationToken cancellationToken)
ExternalAccess\UnitTesting\Api\UnitTestingRemoteHostClient.cs (4)
54public async ValueTask<bool> TryInvokeAsync<TService>(Func<TService, UnitTestingRemoteServiceCallbackIdWrapper, CancellationToken, ValueTask> invocation, object callbackTarget, CancellationToken cancellationToken) where TService : class 60public async ValueTask<Optional<TResult>> TryInvokeAsync<TService, TResult>(Func<TService, UnitTestingRemoteServiceCallbackIdWrapper, CancellationToken, ValueTask<TResult>> invocation, object callbackTarget, CancellationToken cancellationToken) where TService : class 68public async ValueTask<bool> TryInvokeAsync<TService>(Solution solution, Func<TService, UnitTestingPinnedSolutionInfoWrapper, CancellationToken, ValueTask> invocation, CancellationToken cancellationToken) where TService : class 74public async ValueTask<Optional<TResult>> TryInvokeAsync<TService, TResult>(Solution solution, Func<TService, UnitTestingPinnedSolutionInfoWrapper, CancellationToken, ValueTask<TResult>> invocation, CancellationToken cancellationToken) where TService : class
ExternalAccess\UnitTesting\Api\UnitTestingRemoteServiceConnectionWrapper.cs (4)
33public ValueTask<bool> TryInvokeAsync(Func<TService, UnitTestingRemoteServiceCallbackIdWrapper, CancellationToken, ValueTask> invocation, CancellationToken cancellationToken) 38public ValueTask<Optional<TResult>> TryInvokeAsync<TResult>(Func<TService, UnitTestingRemoteServiceCallbackIdWrapper, CancellationToken, ValueTask<TResult>> invocation, CancellationToken cancellationToken) 45public ValueTask<bool> TryInvokeAsync(Solution solution, Func<TService, UnitTestingPinnedSolutionInfoWrapper, CancellationToken, ValueTask> invocation, CancellationToken cancellationToken) 51public ValueTask<Optional<TResult>> TryInvokeAsync<TResult>(Solution solution, Func<TService, UnitTestingPinnedSolutionInfoWrapper, CancellationToken, ValueTask<TResult>> invocation, CancellationToken cancellationToken)
RemoteCallback.cs (1)
99Func<T, PipeWriter, CancellationToken, ValueTask> invocation,
ServiceBrokerExtensions.cs (2)
34protected async ValueTask<TResult> InvokeAsync<TArgs, TResult>(Func<TService, TArgs, CancellationToken, ValueTask<TResult>> operation, TArgs args, CancellationToken cancellationToken) 44protected async ValueTask InvokeAsync<TArgs>(Func<TService, TArgs, CancellationToken, ValueTask> operation, TArgs args, CancellationToken cancellationToken)
Microsoft.CodeAnalysis.Scripting (7)
Hosting\CommandLine\CommandLineRunner.cs (3)
27private readonly Func<string, PEStreamOptions, MetadataReferenceProperties, MetadataImageReference> _createFromFileFunc; 34Func<string, PEStreamOptions, MetadataReferenceProperties, MetadataImageReference>? createFromFileFunc = null) 185Func<string, PEStreamOptions, MetadataReferenceProperties, MetadataImageReference> createFromFileFunc)
Script.cs (1)
316Func<string, PEStreamOptions, MetadataReferenceProperties, MetadataImageReference> createFromFileFunc)
ScriptOptions.cs (3)
143internal Func<string, PEStreamOptions, MetadataReferenceProperties, MetadataImageReference> CreateFromFileFunc { get; private set; } 158Func<string, PEStreamOptions, MetadataReferenceProperties, MetadataImageReference>? createFromFileFunc = null) 393internal ScriptOptions WithCreateFromFileFunc(Func<string, PEStreamOptions, MetadataReferenceProperties, MetadataImageReference> createFromFileFunc)
Microsoft.CodeAnalysis.Test.Utilities (2)
Mocks\TestStream.cs (2)
15private readonly Func<byte[], int, int, int> _readFunc; 26Func<byte[], int, int, int> readFunc = null,
Microsoft.CodeAnalysis.Threading.Package (8)
src\Dependencies\PooledObjects\PooledDelegates.cs (8)
279public static Releaser GetPooledFunction<T1, T2, TArg, TResult>(Func<T1, T2, TArg, TResult> unboundFunction, TArg argument, out Func<T1, T2, TResult> boundFunction) 280=> GetPooledDelegate<FuncWithBoundArgument<T1, T2, TArg, TResult>, TArg, Func<T1, T2, TArg, TResult>, Func<T1, T2, TResult>>(unboundFunction, argument, out boundFunction); 283/// Gets a <see cref="Func{T1, T2, T3, TResult}"/> delegate, which calls <paramref name="unboundFunction"/> with the 315public static Releaser GetPooledFunction<T1, T2, T3, TArg, TResult>(Func<T1, T2, T3, TArg, TResult> unboundFunction, TArg argument, out Func<T1, T2, T3, TResult> boundFunction) 316=> GetPooledDelegate<FuncWithBoundArgument<T1, T2, T3, TArg, TResult>, TArg, Func<T1, T2, T3, TArg, TResult>, Func<T1, T2, T3, TResult>>(unboundFunction, argument, out boundFunction); 437: AbstractDelegateWithBoundArgument<FuncWithBoundArgument<T1, T2, TArg, TResult>, TArg, Func<T1, T2, TArg, TResult>, Func<T1, T2, TResult>> 444: AbstractDelegateWithBoundArgument<FuncWithBoundArgument<T1, T2, T3, TArg, TResult>, TArg, Func<T1, T2, T3, TArg, TResult>, Func<T1, T2, T3, TResult>> 446protected override Func<T1, T2, T3, TResult> Bind()
Microsoft.CodeAnalysis.UnitTests (7)
Collections\IndexOfTests.cs (3)
25Func<TCollection, int, int, int> indexOfItemIndex, 94Func<TCollection, int, IEqualityComparer<int>, int> lastIndexOfItemEQ, 95Func<TCollection, int, int, int> lastIndexOfItemIndex,
Diagnostics\OperationTests.cs (4)
26private static void TestCore(Func<ImmutableArray<IOperation>, ImmutableArray<string>, ImmutableArray<RefKind>, HasDynamicArgumentsExpression> createDynamicExpression) 80Func<ImmutableArray<IOperation>, ImmutableArray<string>, ImmutableArray<RefKind>, HasDynamicArgumentsExpression> createDynamicExpression = 95Func<ImmutableArray<IOperation>, ImmutableArray<string>, ImmutableArray<RefKind>, HasDynamicArgumentsExpression> createDynamicExpression = 110Func<ImmutableArray<IOperation>, ImmutableArray<string>, ImmutableArray<RefKind>, HasDynamicArgumentsExpression> createDynamicExpression =
Microsoft.CodeAnalysis.VisualBasic.Emit.UnitTests (1)
ExpressionTrees\Sources\ExprLambdaUtils.vb (1)
29Public Shared Sub Check(Of T1, T2, T3, T4)(e As Expression(Of Func(Of T1, T2, T3, T4)), expected As String)
Microsoft.CodeAnalysis.VisualBasic.Semantic.UnitTests (1)
FlowAnalysis\FlowTestBase.vb (1)
73Private Function CompileAndGetModelAndSpan(Of T)(program As XElement, analysisDelegate As Func(Of SemanticModel, List(Of VisualBasicSyntaxNode), List(Of VisualBasicSyntaxNode), T), ilSource As XCData, errors As XElement) As T
Microsoft.CodeAnalysis.Workspaces (98)
CodeActions\CodeAction_Cleanup.cs (3)
29private static readonly ImmutableArray<Func<Document, CodeCleanupOptions, CancellationToken, Task<Document>>> s_cleanupPasses = 134foreach (var cleanupPass in s_cleanupPasses) 140Solution solution, Func<Document, CodeCleanupOptions, CancellationToken, Task<Document>> cleanupDocumentAsync)
CodeFixes\FixAllOccurrences\FixAllProvider.cs (3)
58public static FixAllProvider Create(Func<FixAllContext, Document, ImmutableArray<Diagnostic>, Task<Document?>> fixAllAsync) 78Func<FixAllContext, Document, ImmutableArray<Diagnostic>, Task<Document?>> fixAllAsync, 99Func<FixAllContext, Document, ImmutableArray<Diagnostic>, Task<Document?>> fixAllAsync,
CodeRefactorings\FixAllOccurences\FixAllProvider.cs (3)
58public static FixAllProvider Create(Func<FixAllContext, Document, Optional<ImmutableArray<TextSpan>>, Task<Document?>> fixAllAsync) 78Func<FixAllContext, Document, Optional<ImmutableArray<TextSpan>>, Task<Document?>> fixAllAsync, 94Func<FixAllContext, Document, Optional<ImmutableArray<TextSpan>>, Task<Document?>> fixAllAsync,
Editing\SyntaxEditor.cs (2)
167internal void ReplaceNode<TArgument>(SyntaxNode node, Func<SyntaxNode, SyntaxGenerator, TArgument, SyntaxNode> computeReplacement, TArgument argument) 303Func<SyntaxNode, SyntaxGenerator, TArgument, SyntaxNode> modifier,
FindSymbols\FindReferences\Finders\AbstractReferenceFinder.cs (1)
86Func<Document, T, CancellationToken, ValueTask<bool>> predicateAsync,
FindSymbols\FindReferences\FindReferenceCache.cs (1)
191string text, Func<string, SyntaxToken, TArgs, bool> isMatch, TArgs args, CancellationToken cancellationToken)
Remote\RemoteHostClient.cs (10)
81Func<TService, RemoteServiceCallbackId, CancellationToken, ValueTask> invocation, 91Func<TService, RemoteServiceCallbackId, CancellationToken, ValueTask<TResult>> invocation, 104Func<TService, Checksum, CancellationToken, ValueTask> invocation, 113Func<TService, Checksum, CancellationToken, ValueTask> invocation, 123Func<TService, Checksum, CancellationToken, ValueTask<TResult>> invocation, 134/// Equivalent to <see cref="TryInvokeAsync{TService}(Solution, Func{TService, Checksum, CancellationToken, ValueTask}, CancellationToken)"/> 141Func<TService, Checksum, CancellationToken, ValueTask> invocation, 152Func<TService, Checksum, CancellationToken, ValueTask<TResult>> invocation, 161/// Equivalent to <see cref="TryInvokeAsync{TService}(Solution, Func{TService, Checksum, CancellationToken, ValueTask}, CancellationToken)"/> 168Func<TService, Checksum, CancellationToken, ValueTask<TResult>> invocation,
Remote\RemoteServiceConnection.cs (10)
33Func<TService, RemoteServiceCallbackId, CancellationToken, ValueTask> invocation, 37Func<TService, RemoteServiceCallbackId, CancellationToken, ValueTask<TResult>> invocation, 44Func<TService, Checksum, CancellationToken, ValueTask> invocation, 49Func<TService, Checksum, CancellationToken, ValueTask<TResult>> invocation, 54Func<TService, Checksum, CancellationToken, ValueTask> invocation, 60Func<TService, Checksum, CancellationToken, ValueTask<TResult>> invocation, 69Func<TService, Checksum, CancellationToken, ValueTask> invocation, 75Func<TService, Checksum, CancellationToken, ValueTask<TResult>> invocation, 80Func<TService, Checksum, CancellationToken, ValueTask> invocation, 86Func<TService, Checksum, CancellationToken, ValueTask<TResult>> invocation,
Shared\Utilities\StreamingProgressTracker.cs (1)
14internal sealed class StreamingProgressTracker(Func<int, int, CancellationToken, ValueTask>? updateAction = null) : IStreamingProgressTracker
src\Compilers\Core\Portable\Collections\ArrayBuilderExtensions.cs (2)
151public static ImmutableArray<TResult> SelectAsArrayWithIndex<TItem, TArg, TResult>(this ArrayBuilder<TItem> items, Func<TItem, int, TArg, TResult> map, TArg arg) 275public static void RemoveWhere<TItem, TArg>(this ArrayBuilder<TItem> builder, Func<TItem, int, TArg, bool> filter, TArg arg)
src\Compilers\Core\Portable\Collections\ImmutableArrayExtensions.cs (4)
171public static ImmutableArray<TResult> SelectAsArray<TItem, TArg, TResult>(this ImmutableArray<TItem> items, Func<TItem, int, TArg, TResult> map, TArg arg) 439public static async ValueTask<ImmutableArray<TResult>> SelectAsArrayAsync<TItem, TArg, TResult>(this ImmutableArray<TItem> array, Func<TItem, TArg, CancellationToken, ValueTask<TResult>> selector, TArg arg, CancellationToken cancellationToken) 454public static ValueTask<ImmutableArray<TResult>> SelectManyAsArrayAsync<TItem, TArg, TResult>(this ImmutableArray<TItem> source, Func<TItem, TArg, CancellationToken, ValueTask<ImmutableArray<TResult>>> selector, TArg arg, CancellationToken cancellationToken) 1266internal static bool SequenceEqual<TElement, TArg>(this ImmutableArray<TElement> array1, ImmutableArray<TElement> array2, TArg arg, Func<TElement, TElement, TArg, bool> predicate)
src\Compilers\Core\Portable\InternalUtilities\ConcurrentDictionaryExtensions.cs (1)
48Func<TKey, TValue, TArg, TValue> updateValueFactory,
src\Compilers\Core\Portable\InternalUtilities\EnumerableExtensions.cs (2)
511public static async ValueTask<ImmutableArray<TResult>> SelectAsArrayAsync<TItem, TArg, TResult>(this IEnumerable<TItem> source, Func<TItem, TArg, CancellationToken, ValueTask<TResult>> selector, TArg arg, CancellationToken cancellationToken) 523public static async ValueTask<ImmutableArray<TResult>> SelectManyAsArrayAsync<TItem, TArg, TResult>(this IEnumerable<TItem> source, Func<TItem, TArg, CancellationToken, ValueTask<IEnumerable<TResult>>> selector, TArg arg, CancellationToken cancellationToken)
src\Dependencies\PooledObjects\PooledDelegates.cs (8)
279public static Releaser GetPooledFunction<T1, T2, TArg, TResult>(Func<T1, T2, TArg, TResult> unboundFunction, TArg argument, out Func<T1, T2, TResult> boundFunction) 280=> GetPooledDelegate<FuncWithBoundArgument<T1, T2, TArg, TResult>, TArg, Func<T1, T2, TArg, TResult>, Func<T1, T2, TResult>>(unboundFunction, argument, out boundFunction); 283/// Gets a <see cref="Func{T1, T2, T3, TResult}"/> delegate, which calls <paramref name="unboundFunction"/> with the 315public static Releaser GetPooledFunction<T1, T2, T3, TArg, TResult>(Func<T1, T2, T3, TArg, TResult> unboundFunction, TArg argument, out Func<T1, T2, T3, TResult> boundFunction) 316=> GetPooledDelegate<FuncWithBoundArgument<T1, T2, T3, TArg, TResult>, TArg, Func<T1, T2, T3, TArg, TResult>, Func<T1, T2, T3, TResult>>(unboundFunction, argument, out boundFunction); 437: AbstractDelegateWithBoundArgument<FuncWithBoundArgument<T1, T2, TArg, TResult>, TArg, Func<T1, T2, TArg, TResult>, Func<T1, T2, TResult>> 444: AbstractDelegateWithBoundArgument<FuncWithBoundArgument<T1, T2, T3, TArg, TResult>, TArg, Func<T1, T2, T3, TArg, TResult>, Func<T1, T2, T3, TResult>> 446protected override Func<T1, T2, T3, TResult> Bind()
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Extensions\SyntaxNodeExtensions.cs (6)
342Func<SyntaxNode, SyntaxNode, CancellationToken, Task<SyntaxNode>> computeReplacementAsync, 364Func<SyntaxToken, SyntaxToken, CancellationToken, Task<SyntaxToken>> computeReplacementAsync, 377Func<SyntaxTrivia, SyntaxTrivia, CancellationToken, Task<SyntaxTrivia>> computeReplacementAsync, 390Func<SyntaxNode, SyntaxNode, CancellationToken, Task<SyntaxNode>>? computeReplacementNodeAsync, 392Func<SyntaxToken, SyntaxToken, CancellationToken, Task<SyntaxToken>>? computeReplacementTokenAsync, 394Func<SyntaxTrivia, SyntaxTrivia, CancellationToken, Task<SyntaxTrivia>>? computeReplacementTriviaAsync,
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Formatting\Context\FormattingContext.cs (1)
196Func<FormattingContext, IndentBlockOperation, SyntaxToken, int> relativeIndentationDeltaGetter = static (self, operation, effectiveBaseToken) =>
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Formatting\Context\FormattingContext.IndentationData.cs (3)
44private readonly Func<FormattingContext, IndentBlockOperation, SyntaxToken, int> _indentationDeltaGetter; 56public RelativeIndentationData(FormattingContext formattingContext, int inseparableRegionSpanStart, TextSpan textSpan, IndentBlockOperation operation, Func<FormattingContext, IndentBlockOperation, SyntaxToken> effectiveBaseTokenGetter, Func<FormattingContext, IndentBlockOperation, SyntaxToken, int> indentationDeltaGetter, Func<FormattingContext, SyntaxToken, int> baseIndentationGetter) 70private RelativeIndentationData(FormattingContext formattingContext, int inseparableRegionSpanStart, TextSpan textSpan, IndentBlockOperation operation, Func<FormattingContext, IndentBlockOperation, SyntaxToken> effectiveBaseTokenGetter, Func<FormattingContext, IndentBlockOperation, SyntaxToken, int> indentationDeltaGetter, Func<FormattingContext, SyntaxToken, int> baseIndentationGetter, int lazyIndentationDelta)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Formatting\ContextMutableIntervalTree.cs (4)
21private readonly Func<T, int, int, bool> _edgeExclusivePredicate; 22private readonly Func<T, int, int, bool> _edgeInclusivePredicate; 23private readonly Func<T, int, int, bool> _containPredicate; 66private T? GetSmallestContainingIntervalWorker(int start, int length, Func<T, int, int, bool> predicate)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Log\Logger.cs (2)
114public static void Log<TArg0, TArg1, TArg2>(FunctionId functionId, Func<TArg0, TArg1, TArg2, string> messageGetter, TArg0 arg0, TArg1 arg1, TArg2 arg2, LogLevel logLevel = LogLevel.Debug) 201public static IDisposable LogBlock<TArg0, TArg1, TArg2>(FunctionId functionId, Func<TArg0, TArg1, TArg2, string> messageGetter, TArg0 arg0, TArg1 arg1, TArg2 arg2, CancellationToken token, LogLevel logLevel = LogLevel.Trace)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Log\LogMessage.cs (3)
29public static LogMessage Create<TArg0, TArg1, TArg2>(Func<TArg0, TArg1, TArg2, string> messageGetter, TArg0 arg0, TArg1 arg1, TArg2 arg2, LogLevel logLevel) 190private Func<TArg0, TArg1, TArg2, string>? _messageGetter; 195public static LogMessage Construct(Func<TArg0, TArg1, TArg2, string> messageGetter, TArg0 arg0, TArg1 arg1, TArg2 arg2, LogLevel logLevel)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Serialization\ObjectReader.cs (1)
263Func<BinaryReader, T[], int, int> read,
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Utilities\IDictionaryExtensions.cs (1)
232public static void RemoveAll<TKey, TValue, TArg>(this Dictionary<TKey, TValue> dictionary, Func<TKey, TValue, TArg, bool> predicate, TArg arg)
src\Workspaces\SharedUtilitiesAndExtensions\Compiler\Core\Utilities\ProducerConsumer.cs (15)
43Func<ImmutableArray<TItem>, TArgs, CancellationToken, Task> consumeItems, 66Func<Action<TItem>, TArgs, CancellationToken, Task> produceItems, 67Func<ImmutableArray<TItem>, TArgs, CancellationToken, Task> consumeItems, 84Func<Action<TItem>, TArgs, CancellationToken, Task> produceItems, 85Func<IAsyncEnumerable<TItem>, TArgs, CancellationToken, Task> consumeItems, 108Func<IAsyncEnumerable<TItem>, TArgs, CancellationToken, Task> consumeItems, 122Func<IAsyncEnumerable<TItem>, TArgs, CancellationToken, Task> consumeItems, 145Func<ImmutableArray<TItem>, TArgs, CancellationToken, Task> consumeItems, 159Func<ImmutableArray<TItem>, TArgs, CancellationToken, Task> consumeItems, 178Func<IAsyncEnumerable<TItem>, TArgs, CancellationToken, Task<TResult>> consumeItems, 192Func<IAsyncEnumerable<TItem>, TArgs, CancellationToken, Task<TResult>> consumeItems, 244Func<ChannelReader<TItem>, TArgs, CancellationToken, Task<TResult>> consumeItems, 267Func<Action<TItem>, TArgs, CancellationToken, Task> produceItems, 301Func<Action<TItem>, TArgs, CancellationToken, Task> produceItems, 302Func<ChannelReader<TItem>, TArgs, CancellationToken, Task<TResult>> consumeItems,
src\Workspaces\SharedUtilitiesAndExtensions\Workspace\Core\Extensions\SyntaxEditorExtensions.cs (6)
30Func<SemanticModel, TType, TNode, bool> canReplace, 53Func<SemanticModel, TType, TNode, bool> canReplace, 76Func<SemanticModel, SyntaxNode, TNode, SyntaxNode> updateRoot, 97Func<SemanticModel, TType, TNode, bool> canReplace, 120Func<SemanticModel, SyntaxNode, TNode, SyntaxNode> updateRoot, 155Func<SemanticModel, TType, TNode, bool> canReplace,
Workspace\ProjectSystem\ProjectSystemProject.BatchingDocumentCollection.cs (2)
69private readonly Func<Solution, DocumentId, TextLoader, Solution> _documentTextLoaderChangedAction; 76Func<Solution, DocumentId, TextLoader, Solution> documentTextLoaderChangedAction,
Workspace\ProjectSystem\ProjectSystemProject.cs (1)
249Func<SolutionChangeAccumulator, ProjectUpdateState, T, ProjectUpdateState> updateSolution,
Workspace\Solution\SolutionCompilationState.cs (1)
834Func<TDocumentState, TDocumentData, TArg, TDocumentState> updateDocument)
Workspace\Workspace.cs (1)
1254Func<Solution, DocumentId, TArg, Solution> updateSolutionWithText,
Microsoft.CodeAnalysis.Workspaces.MSBuild.BuildHost (17)
src\Compilers\Core\Portable\Collections\ArrayBuilderExtensions.cs (2)
151public static ImmutableArray<TResult> SelectAsArrayWithIndex<TItem, TArg, TResult>(this ArrayBuilder<TItem> items, Func<TItem, int, TArg, TResult> map, TArg arg) 275public static void RemoveWhere<TItem, TArg>(this ArrayBuilder<TItem> builder, Func<TItem, int, TArg, bool> filter, TArg arg)
src\Compilers\Core\Portable\Collections\ImmutableArrayExtensions.cs (4)
171public static ImmutableArray<TResult> SelectAsArray<TItem, TArg, TResult>(this ImmutableArray<TItem> items, Func<TItem, int, TArg, TResult> map, TArg arg) 439public static async ValueTask<ImmutableArray<TResult>> SelectAsArrayAsync<TItem, TArg, TResult>(this ImmutableArray<TItem> array, Func<TItem, TArg, CancellationToken, ValueTask<TResult>> selector, TArg arg, CancellationToken cancellationToken) 454public static ValueTask<ImmutableArray<TResult>> SelectManyAsArrayAsync<TItem, TArg, TResult>(this ImmutableArray<TItem> source, Func<TItem, TArg, CancellationToken, ValueTask<ImmutableArray<TResult>>> selector, TArg arg, CancellationToken cancellationToken) 1266internal static bool SequenceEqual<TElement, TArg>(this ImmutableArray<TElement> array1, ImmutableArray<TElement> array2, TArg arg, Func<TElement, TElement, TArg, bool> predicate)
src\Compilers\Core\Portable\InternalUtilities\ConcurrentDictionaryExtensions.cs (1)
48Func<TKey, TValue, TArg, TValue> updateValueFactory,
src\Compilers\Core\Portable\InternalUtilities\EnumerableExtensions.cs (2)
511public static async ValueTask<ImmutableArray<TResult>> SelectAsArrayAsync<TItem, TArg, TResult>(this IEnumerable<TItem> source, Func<TItem, TArg, CancellationToken, ValueTask<TResult>> selector, TArg arg, CancellationToken cancellationToken) 523public static async ValueTask<ImmutableArray<TResult>> SelectManyAsArrayAsync<TItem, TArg, TResult>(this IEnumerable<TItem> source, Func<TItem, TArg, CancellationToken, ValueTask<IEnumerable<TResult>>> selector, TArg arg, CancellationToken cancellationToken)
src\Dependencies\PooledObjects\PooledDelegates.cs (8)
279public static Releaser GetPooledFunction<T1, T2, TArg, TResult>(Func<T1, T2, TArg, TResult> unboundFunction, TArg argument, out Func<T1, T2, TResult> boundFunction) 280=> GetPooledDelegate<FuncWithBoundArgument<T1, T2, TArg, TResult>, TArg, Func<T1, T2, TArg, TResult>, Func<T1, T2, TResult>>(unboundFunction, argument, out boundFunction); 283/// Gets a <see cref="Func{T1, T2, T3, TResult}"/> delegate, which calls <paramref name="unboundFunction"/> with the 315public static Releaser GetPooledFunction<T1, T2, T3, TArg, TResult>(Func<T1, T2, T3, TArg, TResult> unboundFunction, TArg argument, out Func<T1, T2, T3, TResult> boundFunction) 316=> GetPooledDelegate<FuncWithBoundArgument<T1, T2, T3, TArg, TResult>, TArg, Func<T1, T2, T3, TArg, TResult>, Func<T1, T2, T3, TResult>>(unboundFunction, argument, out boundFunction); 437: AbstractDelegateWithBoundArgument<FuncWithBoundArgument<T1, T2, TArg, TResult>, TArg, Func<T1, T2, TArg, TResult>, Func<T1, T2, TResult>> 444: AbstractDelegateWithBoundArgument<FuncWithBoundArgument<T1, T2, T3, TArg, TResult>, TArg, Func<T1, T2, T3, TArg, TResult>, Func<T1, T2, T3, TResult>> 446protected override Func<T1, T2, T3, TResult> Bind()
Microsoft.CSharp (2)
Microsoft\CSharp\RuntimeBinder\DynamicDebuggerProxy.cs (2)
134var site = CallSite<Func<CallSite, T1, T2, object>>.Create(binder); 374var site = CallSite<Func<CallSite, TObject, TValue, object>>.Create(binder);
Microsoft.DotNet.Build.Tasks.Packaging.Tests (1)
ValidateHarvestVersionIsLatestForReleaseTests.cs (1)
153public Func<string, int, int, string> GetLatestStableVersionFunc { get; set; }
Microsoft.DotNet.NuGetRepack.Tasks (2)
src\NuGetVersionUpdater.cs (2)
61Func<string, string, string, bool> allowPreReleaseDependency = null) 283private static void UpdateDependencies(Dictionary<string, PackageInfo> packages, VersionTranslation translation, bool exactVersions, Func<string, string, string, bool> allowPreReleaseDependencyOpt)
Microsoft.DotNet.RemoteExecutor (3)
RemoteExecutor.cs (3)
223public static RemoteInvokeHandle Invoke(Func<string, string, string, Task<int>> method, string arg1, 291public static RemoteInvokeHandle Invoke(Func<string, string, string, Task> method, string arg1, 359public static RemoteInvokeHandle Invoke(Func<string, string, string, int> method, string arg1,
Microsoft.Extensions.AI (6)
ChatCompletion\AnonymousDelegatingChatClient.cs (2)
34private readonly Func<IEnumerable<ChatMessage>, ChatOptions?, Func<IEnumerable<ChatMessage>, ChatOptions?, CancellationToken, Task>, CancellationToken, Task>? _sharedFunc; 53Func<IEnumerable<ChatMessage>, ChatOptions?, Func<IEnumerable<ChatMessage>, ChatOptions?, CancellationToken, Task>, CancellationToken, Task> sharedFunc)
ChatCompletion\ChatClientBuilder.cs (1)
105public ChatClientBuilder Use(Func<IEnumerable<ChatMessage>, ChatOptions?, Func<IEnumerable<ChatMessage>, ChatOptions?, CancellationToken, Task>, CancellationToken, Task> sharedFunc)
Functions\AIFunctionFactory.cs (2)
1020Func<object?, Type?, CancellationToken, ValueTask<object?>>? marshalResult = key.MarshalResult; 1171Func<object?, Type?, CancellationToken, ValueTask<object?>>? MarshalResult,
Functions\AIFunctionFactoryOptions.cs (1)
107public Func<object?, Type?, CancellationToken, ValueTask<object?>>? MarshalResult { get; set; }
Microsoft.Extensions.AI.Abstractions.Tests (5)
TestChatClient.cs (2)
20public Func<IEnumerable<ChatMessage>, ChatOptions?, CancellationToken, Task<ChatResponse>>? GetResponseAsyncCallback { get; set; } 22public Func<IEnumerable<ChatMessage>, ChatOptions?, CancellationToken, IAsyncEnumerable<ChatResponseUpdate>>? GetStreamingResponseAsyncCallback { get; set; }
TestEmbeddingGenerator.cs (1)
22public Func<IEnumerable<TInput>, EmbeddingGenerationOptions?, CancellationToken, Task<GeneratedEmbeddings<TEmbedding>>>? GenerateAsyncCallback { get; set; }
TestSpeechToTextClient.cs (2)
22public Func<Stream, 29public Func<Stream,
Microsoft.Extensions.AI.Integration.Tests (4)
test\Libraries\Microsoft.Extensions.AI.Abstractions.Tests\TestChatClient.cs (2)
20public Func<IEnumerable<ChatMessage>, ChatOptions?, CancellationToken, Task<ChatResponse>>? GetResponseAsyncCallback { get; set; } 22public Func<IEnumerable<ChatMessage>, ChatOptions?, CancellationToken, IAsyncEnumerable<ChatResponseUpdate>>? GetStreamingResponseAsyncCallback { get; set; }
test\Libraries\Microsoft.Extensions.AI.Abstractions.Tests\TestSpeechToTextClient.cs (2)
22public Func<Stream, 29public Func<Stream,
Microsoft.Extensions.AI.Tests (6)
ChatCompletion\FunctionInvokingChatClientTests.cs (1)
811Func<IEnumerable<ChatMessage>, ChatOptions?, CancellationToken, ChatResponse> callback =
test\Libraries\Microsoft.Extensions.AI.Abstractions.Tests\TestChatClient.cs (2)
20public Func<IEnumerable<ChatMessage>, ChatOptions?, CancellationToken, Task<ChatResponse>>? GetResponseAsyncCallback { get; set; } 22public Func<IEnumerable<ChatMessage>, ChatOptions?, CancellationToken, IAsyncEnumerable<ChatResponseUpdate>>? GetStreamingResponseAsyncCallback { get; set; }
test\Libraries\Microsoft.Extensions.AI.Abstractions.Tests\TestEmbeddingGenerator.cs (1)
22public Func<IEnumerable<TInput>, EmbeddingGenerationOptions?, CancellationToken, Task<GeneratedEmbeddings<TEmbedding>>>? GenerateAsyncCallback { get; set; }
test\Libraries\Microsoft.Extensions.AI.Abstractions.Tests\TestSpeechToTextClient.cs (2)
22public Func<Stream, 29public Func<Stream,
Microsoft.Extensions.DependencyModel (1)
LinqHelpers.cs (1)
27Func<TSource, TParam1, TParam2, IEnumerable<TResult>> func, TParam1 param1, TParam2 param2)
Microsoft.Extensions.Http (1)
Logging\LogHelper.cs (1)
51private static readonly Func<ILogger, HttpMethod, string?, IDisposable?> _beginRequestPipelineScope = LoggerMessage.DefineScope<HttpMethod, string?>("HTTP {HttpMethod} {Uri}");
Microsoft.Extensions.Http.Polly (1)
DependencyInjection\PollyHttpClientBuilderExtensions.cs (1)
254public static IHttpClientBuilder AddPolicyHandler(this IHttpClientBuilder builder, Func<IServiceProvider, HttpRequestMessage, string, IAsyncPolicy<HttpResponseMessage>> policyFactory, Func<HttpRequestMessage, string> keySelector)
Microsoft.Extensions.Http.Polly.Tests (1)
PolicyHttpMessageHandlerTest.cs (1)
414public Func<HttpRequestMessage, Context, CancellationToken, Task<HttpResponseMessage>> OnSendAsync { get; set; }
Microsoft.Extensions.Logging (9)
FilterLoggingBuilderExtensions.cs (3)
20public static ILoggingBuilder AddFilter(this ILoggingBuilder builder, Func<string?, string?, LogLevel, bool> filter) => 109public static LoggerFilterOptions AddFilter(this LoggerFilterOptions builder, Func<string?, string?, LogLevel, bool> filter) => 202Func<string?, string?, LogLevel, bool>? filter = null)
LoggerFactory.cs (1)
233out Func<string?, string?, LogLevel, bool>? filter);
LoggerFilterRule.cs (2)
20public LoggerFilterRule(string? providerName, string? categoryName, LogLevel? logLevel, Func<string?, string?, LogLevel, bool>? filter) 46public Func<string?, string?, LogLevel, bool>? Filter { get; }
LoggerInformation.cs (2)
11public MessageLogger(ILogger logger, string category, string? providerTypeFullName, LogLevel? minLevel, Func<string?, string?, LogLevel, bool>? filter) 28public Func<string?, string?, LogLevel, bool>? Filter { get; }
LoggerRuleSelector.cs (1)
10public static void Select(LoggerFilterOptions options, Type providerType, string category, out LogLevel? minLevel, out Func<string?, string?, LogLevel, bool>? filter)
Microsoft.Extensions.Logging.Abstractions (1)
LoggerMessage.cs (1)
50public static Func<ILogger, T1, T2, IDisposable?> DefineScope<T1, T2>(string formatString)
Microsoft.Extensions.Options (4)
OptionsBuilder.cs (2)
392public virtual OptionsBuilder<TOptions> Validate<TDep1, TDep2>(Func<TOptions, TDep1, TDep2, bool> validation) 405public virtual OptionsBuilder<TOptions> Validate<TDep1, TDep2>(Func<TOptions, TDep1, TDep2, bool> validation, string failureMessage)
ValidateOptions.cs (2)
150public ValidateOptions(string? name, TDep1 dependency1, TDep2 dependency2, Func<TOptions, TDep1, TDep2, bool> validation, string failureMessage) 169public Func<TOptions, TDep1, TDep2, bool> Validation { get; }
Microsoft.Extensions.Telemetry (4)
Logging\ExtendedLoggerFactory.cs (1)
246out Func<string?, string?, LogLevel, bool>? filter);
Logging\Import\LoggerInformation.cs (2)
20public MessageLogger(ILogger logger, string category, string? providerTypeFullName, LogLevel? minLevel, Func<string?, string?, LogLevel, bool>? filter) 45public Func<string?, string?, LogLevel, bool>? Filter { get; }
Logging\Import\LoggerRuleSelector.cs (1)
15public static void Select(LoggerFilterOptions options, Type providerType, string category, out LogLevel? minLevel, out Func<string?, string?, LogLevel, bool>? filter)
Microsoft.ML.Core (6)
ComponentModel\ComponentFactory.cs (3)
76public static IComponentFactory<TArg1, TArg2, TComponent> CreateFromFunction<TArg1, TArg2, TComponent>(Func<IHostEnvironment, TArg1, TArg2, TComponent> factory) 136private readonly Func<IHostEnvironment, TArg1, TArg2, TComponent> _factory; 138public SimpleComponentFactory(Func<IHostEnvironment, TArg1, TArg2, TComponent> factory)
Data\ServerChannel.cs (1)
108public void Register<T1, T2, T3, TRet>(string name, Func<T1, T2, T3, TRet> func)
Utilities\Utils.cs (1)
1105public static TRet MarshalInvoke<TArg1, TArg2, TArg3, TRet>(Func<TArg1, TArg2, TArg3, TRet> func, Type genArg,
Utilities\VBufferUtils.cs (1)
1167public static void ApplyInto<TSrc1, TSrc2, TDst>(in VBuffer<TSrc1> a, in VBuffer<TSrc2> b, ref VBuffer<TDst> dst, Func<int, TSrc1, TSrc2, TDst> func)
Microsoft.ML.Core.Tests (2)
UnitTests\TestVBuffer.cs (2)
501private static void NaiveApplyInto<T1, T2, TDst>(ref VBuffer<T1> a, ref VBuffer<T2> b, ref VBuffer<TDst> dst, Func<int, T1, T2, TDst> func) 526Func<int, float, float, float> func = (int ind, float av, float bv) => 2 * bv + av - ind;
Microsoft.ML.Data (10)
Data\RowCursorUtils.cs (3)
163Func<VectorDataViewType, PrimitiveDataViewType, GetterFactory, ValueGetter<VBuffer<int>>> del = GetVecGetterAsCore<int, int>; 183Func<VectorDataViewType, PrimitiveDataViewType, GetterFactory, ValueGetter<VBuffer<TDst>>> del = GetVecGetterAsCore<int, TDst>; 200Func<VectorDataViewType, PrimitiveDataViewType, GetterFactory, ValueGetter<VBuffer<TDst>>> del = GetVecGetterAsCore<int, TDst>;
DataLoadSave\LegacyCompositeDataLoader.cs (2)
177KeyValuePair<string, string>[] tagData, Func<IHostEnvironment, int, IDataView, IDataView> createTransform) 191KeyValuePair<string, string>[] tagData, Func<IHostEnvironment, int, IDataView, IDataView> createTransform)
Scorers\FeatureContributionCalculation.cs (1)
197Func<DataViewRow, int, VBuffer<ReadOnlyMemory<char>>, ValueGetter<ReadOnlyMemory<char>>> del = GetTextValueGetter<int>;
Transforms\KeyToValue.cs (1)
241Func<int, DataViewType, DataViewType, KeyToValueMap> func = GetKeyMetadata<int, int>;
Transforms\RangeFilter.cs (1)
336Func<RangeFilter, DataViewRowCursor, bool[], DataViewRowCursor> del = CreateKeyRowCursor<int>;
Utilities\ColumnCursor.cs (2)
66Func<IDataView, int, Func<int, T>, IEnumerable<T>> del = GetColumnConvert; 87Func<IDataView, int, Func<int, long>, IEnumerable<long[]>> del = GetColumnArrayConvert;
Microsoft.ML.FastTree (1)
Utils\CompressUtils.cs (1)
19public static IEnumerable<BufferBlock> BlockLoader(Func<byte[], int, int, int> loader, int loadSize)
Microsoft.ML.TestFramework (1)
DataPipe\TestDataPipeBase.cs (1)
1044protected void VerifyVecEquality<T>(ValueGetter<VBuffer<T>> vecGetter, ValueGetter<VBuffer<T>> vecNGetter, Func<int, T, T, bool> compare, int size)
Microsoft.ML.TestFrameworkCommon (1)
TestCommon.cs (1)
136public static bool CompareVec<T>(in VBuffer<T> v1, in VBuffer<T> v2, int size, Func<int, T, T, bool> fn)
Microsoft.ML.Transforms (12)
CountFeatureSelection.cs (2)
354Func<DataViewRow, DataViewType, int, CountAggregator> del = GetOneAggregator<int>; 366Func<DataViewRow, VectorDataViewType, int, CountAggregator> del = GetVecAggregator<int>;
Expression\BuiltinFunctions.cs (1)
102public static MethodInfo Fn<T1, T2, T3, T4>(Func<T1, T2, T3, T4> fn)
Expression\CodeGen.cs (1)
54{ typeFn = typeof(Func<,,,>); break; }
ExpressionTransformer.cs (4)
496var fn = (Func<T0, T1, T2, TDst>)del; 732var fn = (Func<T0, T1, T2, TDst>)del;
MissingValueReplacing.cs (2)
242Func<VBuffer<int>, VectorDataViewType, int, int[]> func = GetValuesArray<int>; 406Func<string, DataViewType, InPredicate<int>, object> func = GetSpecifiedValue<int>;
StatefulFilterTransform.cs (2)
33private readonly Func<TSrc, TDst, TState, bool> _filterFunc; 54public StatefulFilterTransform(IHostEnvironment env, IDataView source, Func<TSrc, TDst, TState, bool> filterFunc,
Microsoft.VisualBasic.Core (7)
Microsoft\VisualBasic\CompilerServices\IDOBinder.vb (7)
1330Private Shared Invokers As New CacheDict(Of Integer, Func(Of CallSiteBinder, Object, Object(), Object))(16) 1340Dim Invoker As Func(Of CallSiteBinder, Object, Object(), Object) = Nothing 1363Private Shared Function CreateInvoker(ByVal ArgLength As Integer) As Func(Of CallSiteBinder, Object, Object(), Object) 1405Return DirectCast(InvokerMethod.CreateDelegate(GetType(Func(Of CallSiteBinder, Object, Object(), Object))), Func(Of CallSiteBinder, Object, Object(), Object)) 1422Dim c As CallSite(Of Func(Of CallSite, Object, Object, Object)) = 1423CallSite(Of Func(Of CallSite, Object, Object, Object)).Create(action)
Microsoft.VisualStudio.LanguageServices (3)
EditorConfigSettings\SettingsEditorPane.cs (1)
157Func<ISettingsProvider<TData>, IWpfTableControlProvider, ITableManagerProvider, IWpfSettingsEditorViewModel> createViewModel,
Library\ObjectBrowser\AbstractListItemFactory.cs (2)
171Func<TSymbol, ProjectId, bool, ObjectListItem> listItemCreator) 185Func<TSymbol, ProjectId, bool, ObjectListItem> listItemCreator,
MSBuild (1)
ManagedFileSystem.cs (1)
61Func<string, string, Microsoft.IO.SearchOption, IEnumerable<string>> enumerateFunctionDelegate,
mscorlib (1)
src\libraries\shims\mscorlib\ref\mscorlib.cs (1)
237[assembly: System.Runtime.CompilerServices.TypeForwardedTo(typeof(System.Func<,,,>))]
netstandard (1)
netstandard.cs (1)
805[assembly: System.Runtime.CompilerServices.TypeForwardedTo(typeof(System.Func<,,,>))]
PresentationFramework (2)
System\Windows\Controls\ItemContainerGenerator.cs (2)
626internal bool FindItem<TState>(Func<TState, object, DependencyObject, bool> match, TState matchState, 676private bool DoLinearSearch<TState>(Func<TState, object, DependencyObject, bool> match, TState matchState,
Roslyn.VisualStudio.Next.UnitTests (5)
Remote\SerializationValidator.cs (1)
196Func<T, WellKnownSynchronizationKind, ISerializerService, SolutionAsset> assetGetter)
Services\ServiceHubServicesTests_ExtensionMessageHandler.cs (4)
245Func<Assembly, string, CancellationToken, ImmutableArray<IExtensionMessageHandlerWrapper<Solution>>> createWorkspaceMessageHandlersCallback, 246Func<Assembly, string, CancellationToken, ImmutableArray<IExtensionMessageHandlerWrapper<Document>>> createDocumentMessageHandlersCallback) 776public Func<Assembly, string, CancellationToken, ImmutableArray<IExtensionMessageHandlerWrapper<Solution>>>? CreateWorkspaceMessageHandlersCallback { get; set; } 777public Func<Assembly, string, CancellationToken, ImmutableArray<IExtensionMessageHandlerWrapper<Document>>>? CreateDocumentMessageHandlersCallback { get; set; }
ScenarioTests.Common.Tests (2)
TestMockStream.cs (2)
29public Func<Stream, int, CancellationToken, Task> CopyToAsyncFunc { get; set; } 32public Func<byte[], int, int, int> ReadFunc { get; set; }
System.Collections.Concurrent (1)
System\Collections\Concurrent\ConcurrentDictionary.cs (1)
1327TKey key, Func<TKey, TArg, TValue> addValueFactory, Func<TKey, TValue, TArg, TValue> updateValueFactory, TArg factoryArgument)
System.Composition.Hosting (2)
System\Composition\Hosting\Providers\ImportMany\ImportManyExportDescriptorProvider.cs (2)
35var gimdm = gimd.CreateStaticDelegate<Func<CompositionContract, CompositionContract, DependencyAccessor, object>>();
System.Composition.TypedParts (2)
System\Composition\TypedParts\ActivationFeatures\PropertyInjectionFeature.cs (2)
103var setAction = Expression.Lambda<Func<object, LifetimeContext, CompositionOperation, object>>(
System.Core (1)
System.Core.cs (1)
95[assembly: System.Runtime.CompilerServices.TypeForwardedTo(typeof(System.Func<,,,>))]
System.Data.Common (3)
System\Data\SQLTypes\SqlXml.cs (3)
19private static readonly Func<Stream, XmlReaderSettings, XmlParserContext?, XmlReader> s_sqlReaderDelegate = CreateSqlReaderDelegate(); 118private static Func<Stream, XmlReaderSettings, XmlParserContext?, XmlReader> CreateSqlReaderDelegate() 122return CreateSqlReaderMethodInfo.CreateDelegate<Func<Stream, XmlReaderSettings, XmlParserContext?, XmlReader>>();
System.Diagnostics.DiagnosticSource (4)
System\Diagnostics\DiagnosticListener.cs (3)
108public virtual IDisposable Subscribe(IObserver<KeyValuePair<string, object?>> observer, Func<string, object?, object?, bool>? isEnabled) 279internal Func<string, object?, object?, bool>? IsEnabled3Arg; 430Predicate<string>? isEnabled1Arg, Func<string, object?, object?, bool>? isEnabled3Arg,
System\Diagnostics\DiagnosticSourceActivity.cs (1)
143public virtual IDisposable Subscribe(IObserver<KeyValuePair<string, object?>> observer, Func<string, object?, object?, bool>? isEnabled,
System.IO.Pipelines (1)
System\IO\Pipelines\PipeReader.cs (1)
232private async Task CopyToAsyncCore<TStream>(TStream destination, Func<TStream, ReadOnlyMemory<byte>, CancellationToken, ValueTask<FlushResult>> writeAsync, CancellationToken cancellationToken)
System.Linq.AsyncEnumerable (45)
System\Linq\AggregateAsync.cs (6)
65Func<TSource, TSource, CancellationToken, ValueTask<TSource>> func, 75Func<TSource, TSource, CancellationToken, ValueTask<TSource>> func, 144Func<TAccumulate, TSource, CancellationToken, ValueTask<TAccumulate>> func, 154Func<TAccumulate, TSource, CancellationToken, ValueTask<TAccumulate>> func, 235Func<TAccumulate, TSource, CancellationToken, ValueTask<TAccumulate>> func, 248Func<TAccumulate, TSource, CancellationToken, ValueTask<TAccumulate>> func,
System\Linq\AggregateBy.cs (4)
108Func<TAccumulate, TSource, CancellationToken, ValueTask<TAccumulate>> func, 124Func<TAccumulate, TSource, CancellationToken, ValueTask<TAccumulate>> func, 247Func<TAccumulate, TSource, CancellationToken, ValueTask<TAccumulate>> func, 263Func<TAccumulate, TSource, CancellationToken, ValueTask<TAccumulate>> func,
System\Linq\GroupBy.cs (4)
253Func<TKey, IEnumerable<TSource>, CancellationToken, ValueTask<TResult>> resultSelector, 267Func<TKey, IEnumerable<TSource>, CancellationToken, ValueTask<TResult>> resultSelector, 359Func<TKey, IEnumerable<TElement>, CancellationToken, ValueTask<TResult>> resultSelector, 375Func<TKey, IEnumerable<TElement>, CancellationToken, ValueTask<TResult>> resultSelector,
System\Linq\GroupJoin.cs (2)
106Func<TOuter, IEnumerable<TInner>, CancellationToken, ValueTask<TResult>> resultSelector, 124Func<TOuter, IEnumerable<TInner>, CancellationToken, ValueTask<TResult>> resultSelector,
System\Linq\Join.cs (2)
111Func<TOuter, TInner, CancellationToken, ValueTask<TResult>> resultSelector, 129Func<TOuter, TInner, CancellationToken, ValueTask<TResult>> resultSelector,
System\Linq\LeftJoin.cs (2)
106Func<TOuter, TInner?, CancellationToken, ValueTask<TResult>> resultSelector, 124Func<TOuter, TInner?, CancellationToken, ValueTask<TResult>> resultSelector,
System\Linq\RightJoin.cs (2)
107Func<TOuter?, TInner, CancellationToken, ValueTask<TResult>> resultSelector, 125Func<TOuter?, TInner, CancellationToken, ValueTask<TResult>> resultSelector,
System\Linq\Select.cs (2)
135Func<TSource, int, CancellationToken, ValueTask<TResult>> selector) 146Func<TSource, int, CancellationToken, ValueTask<TResult>> selector,
System\Linq\SelectMany.cs (12)
192Func<TSource, int, CancellationToken, ValueTask<IEnumerable<TResult>>> selector) 203Func<TSource, int, CancellationToken, ValueTask<IEnumerable<TResult>>> selector, 333Func<TSource, TCollection, CancellationToken, ValueTask<TResult>> resultSelector) 346Func<TSource, TCollection, CancellationToken, ValueTask<TResult>> resultSelector, 433Func<TSource, TCollection, CancellationToken, ValueTask<TResult>> resultSelector) 446Func<TSource, TCollection, CancellationToken, ValueTask<TResult>> resultSelector, 531Func<TSource, int, CancellationToken, ValueTask<IEnumerable<TCollection>>> collectionSelector, 532Func<TSource, TCollection, CancellationToken, ValueTask<TResult>> resultSelector) 544Func<TSource, int, CancellationToken, ValueTask<IEnumerable<TCollection>>> collectionSelector, 545Func<TSource, TCollection, CancellationToken, ValueTask<TResult>> resultSelector, 582Func<TSource, TCollection, CancellationToken, ValueTask<TResult>> resultSelector) 595Func<TSource, TCollection, CancellationToken, ValueTask<TResult>> resultSelector,
System\Linq\SkipWhile.cs (2)
185Func<TSource, int, CancellationToken, ValueTask<bool>> predicate) 196Func<TSource, int, CancellationToken, ValueTask<bool>> predicate,
System\Linq\TakeWhile.cs (2)
145Func<TSource, int, CancellationToken, ValueTask<bool>> predicate) 156Func<TSource, int, CancellationToken, ValueTask<bool>> predicate,
System\Linq\ToLookupAsync.cs (1)
426Func<TKey, IEnumerable<TElement>, CancellationToken, ValueTask<TResult>> resultSelector,
System\Linq\Where.cs (2)
134Func<TSource, int, CancellationToken, ValueTask<bool>> predicate) 145Func<TSource, int, CancellationToken, ValueTask<bool>> predicate,
System\Linq\Zip.cs (2)
74Func<TFirst, TSecond, CancellationToken, ValueTask<TResult>> resultSelector) 87Func<TFirst, TSecond, CancellationToken, ValueTask<TResult>> resultSelector,
System.Linq.Expressions (9)
System\Dynamic\UpdateDelegates.Generated.cs (3)
165var @this = (CallSite<Func<CallSite, T0, T1, TRet>>)site; 166Func<CallSite, T0, T1, TRet>[] applicable; 167Func<CallSite, T0, T1, TRet> rule, originalRule = @this.Target;
System\Linq\Expressions\Compiler\DelegateHelpers.Generated.cs (1)
199return typeof(Func<,,,>).MakeGenericType(types);
System\Linq\Expressions\Interpreter\CallInstruction.Generated.cs (3)
501private readonly Func<T0, T1, T2, TRet> _target; 508_target = (Func<T0, T1, T2, TRet>)target.CreateDelegate(typeof(Func<T0, T1, T2, TRet>));
System\Linq\Expressions\StackGuard.cs (2)
54public R RunOnEmptyStack<T1, T2, T3, R>(Func<T1, T2, T3, R> action, T1 arg1, T2 arg2, T3 arg3) => 57var t = ((Func<T1, T2, T3, R>, T1, T2, T3))s;
System.Net.Http.Json (9)
System\Net\Http\Json\HttpClientJsonExtensions.cs (7)
19private static Task<object?> FromJsonAsyncCore(Func<HttpClient, Uri?, CancellationToken, Task<HttpResponseMessage>> getMethod, HttpClient client, Uri? requestUri, Type type, JsonSerializerOptions? options, CancellationToken cancellationToken = default) => 24private static Task<TValue?> FromJsonAsyncCore<TValue>(Func<HttpClient, Uri?, CancellationToken, Task<HttpResponseMessage>> getMethod, HttpClient client, Uri? requestUri, JsonSerializerOptions? options, CancellationToken cancellationToken = default) => 27private static Task<object?> FromJsonAsyncCore(Func<HttpClient, Uri?, CancellationToken, Task<HttpResponseMessage>> getMethod, HttpClient client, Uri? requestUri, Type type, JsonSerializerContext context, CancellationToken cancellationToken = default) => 30private static Task<TValue?> FromJsonAsyncCore<TValue>(Func<HttpClient, Uri?, CancellationToken, Task<HttpResponseMessage>> getMethod, HttpClient client, Uri? requestUri, JsonTypeInfo<TValue> jsonTypeInfo, CancellationToken cancellationToken) => 34Func<HttpClient, Uri?, CancellationToken, Task<HttpResponseMessage>> getMethod, 37Func<Stream, TJsonOptions, CancellationToken, ValueTask<TValue?>> deserializeMethod, 75Func<Stream, TJsonOptions, CancellationToken, ValueTask<TValue?>> deserializeMethod,
System\Net\Http\Json\HttpClientJsonExtensions.Delete.cs (1)
18private static readonly Func<HttpClient, Uri?, CancellationToken, Task<HttpResponseMessage>> s_deleteAsync =
System\Net\Http\Json\HttpClientJsonExtensions.Get.cs (1)
18private static readonly Func<HttpClient, Uri?, CancellationToken, Task<HttpResponseMessage>> s_getAsync =
System.Net.HttpListener (3)
System\Net\Windows\CookieExtensions.cs (3)
52private static Func<CookieCollection, Cookie, bool, int>? s_internalAddFunc; 56s_internalAddFunc ??= (Func<CookieCollection, Cookie, bool, int>)typeof(CookieCollection).GetMethod("InternalAdd", BindingFlags.Instance | BindingFlags.NonPublic)?.CreateDelegate(typeof(Func<CookieCollection, Cookie, bool, int>))!;
System.Net.Quic (2)
System\Net\Quic\QuicListener.cs (1)
94private readonly Func<QuicConnection, SslClientHelloInfo, CancellationToken, ValueTask<QuicServerConnectionOptions>> _connectionOptionsCallback;
System\Net\Quic\QuicListenerOptions.cs (1)
37public Func<QuicConnection, SslClientHelloInfo, CancellationToken, ValueTask<QuicServerConnectionOptions>> ConnectionOptionsCallback { get; set; } = null!;
System.Net.Security (2)
src\libraries\Common\src\System\Net\Http\X509ResourceClient.cs (2)
18private static readonly Func<string, CancellationToken, bool, Task<byte[]?>>? s_downloadBytes = CreateDownloadBytesFunc(); 83private static Func<string, CancellationToken, bool, Task<byte[]?>>? CreateDownloadBytesFunc()
System.Private.CoreLib (16)
src\libraries\System.Private.CoreLib\src\Microsoft\Win32\SafeHandles\SafeFileHandle.Unix.cs (4)
92Func<Interop.ErrorInfo, Interop.Sys.OpenFlags, string, Exception?>? createOpenException) 185Func<Interop.ErrorInfo, Interop.Sys.OpenFlags, string, Exception?>? createOpenException = null) 191Func<Interop.ErrorInfo, Interop.Sys.OpenFlags, string, Exception?>? createOpenException = null) 198Func<Interop.ErrorInfo, Interop.Sys.OpenFlags, string, Exception?>? createOpenException = null)
src\libraries\System.Private.CoreLib\src\System\Threading\Tasks\FutureFactory.cs (3)
825Func<TArg1, AsyncCallback, object?, IAsyncResult> beginMethod, 859Func<TArg1, AsyncCallback, object?, IAsyncResult> beginMethod, 868internal static Task<TResult> FromAsyncImpl<TArg1>(Func<TArg1, AsyncCallback, object?, IAsyncResult> beginMethod,
src\libraries\System.Private.CoreLib\src\System\Threading\Tasks\TaskFactory.cs (4)
935Func<TArg1, AsyncCallback, object?, IAsyncResult> beginMethod, 971Func<TArg1, AsyncCallback, object?, IAsyncResult> beginMethod, 1303Func<TArg1, AsyncCallback, object?, IAsyncResult> beginMethod, 1338public Task<TResult> FromAsync<TArg1, TResult>(Func<TArg1, AsyncCallback, object?, IAsyncResult> beginMethod,
src\System\Reflection\TypeNameResolver.CoreCLR.cs (2)
18private Func<Assembly?, string, bool, Type?>? _typeResolver; 42Func<Assembly?, string, bool, Type?>? typeResolver,
src\System\Type.CoreCLR.cs (3)
45Func<Assembly?, string, bool, Type?>? typeResolver) 57Func<Assembly?, string, bool, Type?>? typeResolver, 71Func<Assembly?, string, bool, Type?>? typeResolver,
System.Reflection.MetadataLoadContext (1)
System\Reflection\TypeLoading\General\Helpers.cs (1)
310Func<Assembly?, string, bool, Type?> typeResolver =
System.Runtime (1)
artifacts\obj\System.Runtime\Debug\net10.0\System.Runtime.Forwards.cs (1)
203[assembly: System.Runtime.CompilerServices.TypeForwardedTo(typeof(System.Func<,,,>))]
System.Runtime.InteropServices.JavaScript (2)
artifacts\obj\System.Runtime.InteropServices.JavaScript\Debug\net10.0\System.Runtime.InteropServices.JavaScript.notsupported.cs (2)
296public void ToManaged<T1, T2, T3, TResult>(out Func<T1, T2, T3, TResult>? value, ArgumentToJSCallback<T1> arg1Marshaler, ArgumentToJSCallback<T2> arg2Marshaler, ArgumentToJSCallback<T3> arg3Marshaler, ArgumentToManagedCallback<TResult> resMarshaler) { throw new System.PlatformNotSupportedException(System.SR.SystemRuntimeInteropServicesJavaScript_PlatformNotSupported); } 297public void ToJS<T1, T2, T3, TResult>(Func<T1, T2, T3, TResult>? value, ArgumentToManagedCallback<T1> arg1Marshaler, ArgumentToManagedCallback<T2> arg2Marshaler, ArgumentToManagedCallback<T3> arg3Marshaler, ArgumentToJSCallback<TResult> resMarshaler) { throw new System.PlatformNotSupportedException(System.SR.SystemRuntimeInteropServicesJavaScript_PlatformNotSupported); }
System.Security.Cryptography (4)
src\libraries\Common\src\Interop\Unix\System.Security.Cryptography.Native\Interop.EvpPkey.ExportKeyContents.cs (1)
15Func<SafeEvpPKeyHandle, Span<byte>, int, int> action)
src\libraries\Common\src\System\Net\Http\X509ResourceClient.cs (2)
18private static readonly Func<string, CancellationToken, bool, Task<byte[]?>>? s_downloadBytes = CreateDownloadBytesFunc(); 83private static Func<string, CancellationToken, bool, Task<byte[]?>>? CreateDownloadBytesFunc()
System\Security\Cryptography\FixedMemoryKeyBox.cs (1)
54Func<ReadOnlySpan<byte>, TState, ReadOnlySpan<byte>, TRet> func)
System.Text.RegularExpressions (1)
System\Threading\StackHelper.cs (1)
157public static TResult CallOnEmptyStack<TArg1, TArg2, TArg3, TResult>(Func<TArg1, TArg2, TArg3, TResult> func, TArg1 arg1, TArg2 arg2, TArg3 arg3) =>
System.Text.RegularExpressions.Generator (1)
src\libraries\System.Text.RegularExpressions\src\System\Threading\StackHelper.cs (1)
157public static TResult CallOnEmptyStack<TArg1, TArg2, TArg3, TResult>(Func<TArg1, TArg2, TArg3, TResult> func, TArg1 arg1, TArg2 arg2, TArg3 arg3) =>
System.Threading.Tasks.Dataflow (3)
Blocks\BatchBlock.cs (1)
58Func<ISourceBlock<T[]>, T[], IList<T[]>?, int>? itemCountingFunc = null;
Internal\SourceCore.cs (2)
74private readonly Func<ISourceBlock<TOutput>, TOutput, IList<TOutput>?, int>? _itemCountingFunc; 106Func<ISourceBlock<TOutput>, TOutput, IList<TOutput>?, int>? itemCountingFunc = null)
System.Threading.Tasks.Parallel (13)
System\Threading\Tasks\Parallel.cs (13)
693Func<int, ParallelLoopState, TLocal, TLocal> body, 746Func<long, ParallelLoopState, TLocal, TLocal> body, 810Func<int, ParallelLoopState, TLocal, TLocal> body, 875Func<long, ParallelLoopState, TLocal, TLocal> body, 919Func<TInt, ParallelLoopState, TLocal, TLocal>? bodyWithLocal, 1417Func<TSource, ParallelLoopState, TLocal, TLocal> body, Action<TLocal> localFinally) 1482Func<TSource, ParallelLoopState, TLocal, TLocal> body, Action<TLocal> localFinally) 1641Func<TSource, ParallelLoopState, TLocal, TLocal>? bodyWithStateAndLocal, 1699Func<TSource, ParallelLoopState, TLocal, TLocal>? bodyWithStateAndLocal, 1758Func<TSource, ParallelLoopState, TLocal, TLocal>? bodyWithStateAndLocal, 2023Func<TSource, ParallelLoopState, TLocal, TLocal> body, 2397Func<TSource, ParallelLoopState, TLocal, TLocal> body, 2512Func<TSource, ParallelLoopState, TLocal, TLocal>? bodyWithStateAndLocal,
System.Xaml.Tests (1)
Common\Optional.cs (1)
20public readonly T Or<TArg1, TArg2, TArg3>(Func<TArg1, TArg2, TArg3, T> valueFactory, TArg1 arg1, TArg2 arg2, TArg3 arg3) => HasValue ? Value : valueFactory(arg1, arg2, arg3);
UnitTests.Common (9)
IMockCommunicationObject.cs (2)
18Func<TimeSpan, AsyncCallback, object, IAsyncResult> OnBeginCloseOverride { get; set; } 19Func<TimeSpan, AsyncCallback, object, IAsyncResult> OnBeginOpenOverride { get; set; }
MockChannelBase.cs (2)
58public Func<TimeSpan, AsyncCallback, object, IAsyncResult> OnBeginCloseOverride { get; set; } 59public Func<TimeSpan, AsyncCallback, object, IAsyncResult> OnBeginOpenOverride { get; set; }
MockChannelFactory.cs (2)
57public Func<TimeSpan, AsyncCallback, object, IAsyncResult> OnBeginCloseOverride { get; set; } 58public Func<TimeSpan, AsyncCallback, object, IAsyncResult> OnBeginOpenOverride { get; set; }
MockCommunicationObject.cs (2)
53public Func<TimeSpan, AsyncCallback, object, IAsyncResult> OnBeginCloseOverride { get; set; } 54public Func<TimeSpan, AsyncCallback, object, IAsyncResult> OnBeginOpenOverride { get; set; }
MockInteractiveChannelInitializer.cs (1)
19public Func<IClientChannel, AsyncCallback, object, IAsyncResult> BeginDisplayInitializationUIOverride { get; set; }
WindowsBase.Tests (7)
System\Collections\Specialized\CollectionChangedEventManagerTests.cs (1)
554public Func<Type, object, EventArgs, bool>? ReceiveWeakEventAction { get; set; }
System\ComponentModel\CurrentChangedEventManagerTests.cs (1)
629public Func<Type, object, EventArgs, bool>? ReceiveWeakEventAction { get; set; }
System\ComponentModel\CurrentChangingEventManagerTests.cs (1)
611public Func<Type, object, EventArgs, bool>? ReceiveWeakEventAction { get; set; }
System\ComponentModel\ErrorsChangedEventManagerTests.cs (1)
273public Func<Type, object, EventArgs, bool>? ReceiveWeakEventAction { get; set; }
System\ComponentModel\PropertyChangedEventManagerTests.cs (1)
1260public Func<Type, object, EventArgs, bool>? ReceiveWeakEventAction { get; set; }
System\Windows\WeakEventManagerTests.cs (2)
6051public Func<object, EventArgs, Type, bool>? DeliverEventAction { get; set; } 6066public Func<Type, object, EventArgs, bool>? ReceiveWeakEventAction { get; set; }