Search Results for

    Show / Hide Table of Contents

    Class Flow<TIn, TOut, TMat>

    A Flow<TIn, TOut, TMat> is a set of stream processing steps that has one open input and one open output.

    Inheritance
    object
    Flow<TIn, TOut, TMat>
    Implements
    IFlow<TOut, TMat>
    IGraph<FlowShape<TIn, TOut>, TMat>
    IGraph<FlowShape<TIn, TOut>>
    Inherited Members
    object.Equals(object)
    object.Equals(object, object)
    object.GetHashCode()
    object.GetType()
    object.ReferenceEquals(object, object)
    Namespace: Akka.Streams.Dsl
    Assembly: Akka.Streams.dll
    Syntax
    public sealed class Flow<TIn, TOut, TMat> : IFlow<TOut, TMat>, IGraph<FlowShape<TIn, TOut>, TMat>, IGraph<FlowShape<TIn, TOut>>
    Type Parameters
    Name Description
    TIn

    Type of the flow input.

    TOut

    Type of the flow output.

    TMat

    Type of value, flow graph may materialize to.

    Properties

    | Edit this page View Source

    Module

    TBD

    Declaration
    public IModule Module { get; }
    Property Value
    Type Description
    IModule
    | Edit this page View Source

    Shape

    TBD

    Declaration
    public FlowShape<TIn, TOut> Shape { get; }
    Property Value
    Type Description
    FlowShape<TIn, TOut>

    Methods

    | Edit this page View Source

    AddAttributes(Attributes)

    Add the given attributes to this Flow<TIn, TOut, TMat>. Further calls to WithAttributes(Attributes) will not remove these attributes. Note that this operation has no effect on an empty Flow (because the attributes apply only to the contained processing stages).

    Declaration
    public Flow<TIn, TOut, TMat> AddAttributes(Attributes attributes)
    Parameters
    Type Name Description
    Attributes attributes

    TBD

    Returns
    Type Description
    Flow<TIn, TOut, TMat>

    TBD

    | Edit this page View Source

    Ask<TOut2>(IActorRef, TimeSpan, int)

    Use the ask pattern to send a request-reply message to the target actorRef. If any of the asks times out it will fail the stream with a AskTimeoutException.

    Parallelism limits the number of how many asks can be "in flight" at the same time. Please note that the elements emitted by this operator are in-order with regards to the asks being issued (i.e. same behaviour as SelectAsync<TIn, TOut, TMat>(Source<TIn, TMat>, int, Func<TIn, Task<TOut>>)).

    The operator fails with an WatchedActorTerminatedException if the target actor is terminated, or with an TimeoutException in case the ask exceeds the timeout passed in.

    Adheres to the ActorAttributes.SupervisionStrategy attribute.

    '''Emits when''' the futures (in submission order) created by the ask pattern internally are completed. '''Backpressures when''' the number of futures reaches the configured parallelism and the downstream backpressures. '''Completes when''' upstream completes and all futures have been completed and all elements have been emitted. '''Fails when''' the passed in actor terminates, or a timeout is exceeded in any of the asks performed. '''Cancels when''' downstream cancels.

    Declaration
    public Flow<TIn, TOut2, TMat> Ask<TOut2>(IActorRef actorRef, TimeSpan timeout, int parallelism = 2)
    Parameters
    Type Name Description
    IActorRef actorRef
    TimeSpan timeout
    int parallelism
    Returns
    Type Description
    Flow<TIn, TOut2, TMat>
    Type Parameters
    Name Description
    TOut2
    | Edit this page View Source

    Async()

    Put an asynchronous boundary around this Source.

    Declaration
    public Flow<TIn, TOut, TMat> Async()
    Returns
    Type Description
    Flow<TIn, TOut, TMat>

    TBD

    | Edit this page View Source

    ConcatMaterialized<TMat2, TMat3>(IGraph<SourceShape<TOut>, TMat2>, Func<TMat, TMat2, TMat3>)

    Concatenate the given Source<TOut, TMat> to this Flow<TIn, TOut, TMat>, meaning that once this Flow’s input is exhausted and all result elements have been generated, the Source’s elements will be produced.

    Note that the Source<TOut, TMat> is materialized together with this Flow and just kept from producing elements by asserting back-pressure until its time comes.

    If this Flow<TIn, TOut, TMat> gets upstream error - no elements from the given Source<TOut, TMat> will be pulled.

    @see Concat<TIn, TOut>.

    It is recommended to use the internally optimized Left<TLeft, TRight>(TLeft, TRight) and Right<TLeft, TRight>(TLeft, TRight) combiners where appropriate instead of manually writing functions that pass through one of the values.

    Declaration
    public Flow<TIn, TOut, TMat3> ConcatMaterialized<TMat2, TMat3>(IGraph<SourceShape<TOut>, TMat2> that, Func<TMat, TMat2, TMat3> materializedFunction)
    Parameters
    Type Name Description
    IGraph<SourceShape<TOut>, TMat2> that

    TBD

    Func<TMat, TMat2, TMat3> materializedFunction

    TBD

    Returns
    Type Description
    Flow<TIn, TOut, TMat3>

    TBD

    Type Parameters
    Name Description
    TMat2

    TBD

    TMat3

    TBD

    | Edit this page View Source

    JoinMaterialized<TMat2, TMat3>(IGraph<FlowShape<TOut, TIn>, TMat2>, Func<TMat, TMat2, TMat3>)

    Join this Flow<TIn, TOut, TMat> to another Flow<TIn, TOut, TMat>, by cross connecting the inputs and outputs, creating a IRunnableGraph<TMat> The combine function is used to compose the materialized values of this flow and that Flow into the materialized value of the resulting Flow.

    Declaration
    public IRunnableGraph<TMat3> JoinMaterialized<TMat2, TMat3>(IGraph<FlowShape<TOut, TIn>, TMat2> flow, Func<TMat, TMat2, TMat3> combine)
    Parameters
    Type Name Description
    IGraph<FlowShape<TOut, TIn>, TMat2> flow

    TBD

    Func<TMat, TMat2, TMat3> combine

    TBD

    Returns
    Type Description
    IRunnableGraph<TMat3>

    TBD

    Type Parameters
    Name Description
    TMat2

    TBD

    TMat3

    TBD

    | Edit this page View Source

    JoinMaterialized<TIn2, TOut2, TMat2, TMatRes>(IGraph<BidiShape<TOut, TOut2, TIn2, TIn>, TMat2>, Func<TMat, TMat2, TMatRes>)

    TBD

    Declaration
    public Flow<TIn2, TOut2, TMatRes> JoinMaterialized<TIn2, TOut2, TMat2, TMatRes>(IGraph<BidiShape<TOut, TOut2, TIn2, TIn>, TMat2> bidi, Func<TMat, TMat2, TMatRes> combine)
    Parameters
    Type Name Description
    IGraph<BidiShape<TOut, TOut2, TIn2, TIn>, TMat2> bidi

    TBD

    Func<TMat, TMat2, TMatRes> combine

    TBD

    Returns
    Type Description
    Flow<TIn2, TOut2, TMatRes>

    TBD

    Type Parameters
    Name Description
    TIn2

    TBD

    TOut2

    TBD

    TMat2

    TBD

    TMatRes

    TBD

    | Edit this page View Source

    Join<TMat2>(IGraph<FlowShape<TOut, TIn>, TMat2>)

    Join this Flow<TIn, TOut, TMat> to another Flow<TIn, TOut, TMat>, by cross connecting the inputs and outputs, creating a IRunnableGraph<TMat>. The materialized value of the combined Flow<TIn, TOut, TMat> will be the materialized value of the current flow (ignoring the other Flow’s value), use JoinMaterialized<TMat2, TMat3>(IGraph<FlowShape<TOut, TIn>, TMat2>, Func<TMat, TMat2, TMat3>) if a different strategy is needed.

    Declaration
    public IRunnableGraph<TMat> Join<TMat2>(IGraph<FlowShape<TOut, TIn>, TMat2> flow)
    Parameters
    Type Name Description
    IGraph<FlowShape<TOut, TIn>, TMat2> flow

    TBD

    Returns
    Type Description
    IRunnableGraph<TMat>

    TBD

    Type Parameters
    Name Description
    TMat2

    TBD

    | Edit this page View Source

    Join<TIn2, TOut2, TMat2>(IGraph<BidiShape<TOut, TOut2, TIn2, TIn>, TMat2>)

    TBD

    Declaration
    public Flow<TIn2, TOut2, TMat> Join<TIn2, TOut2, TMat2>(IGraph<BidiShape<TOut, TOut2, TIn2, TIn>, TMat2> bidi)
    Parameters
    Type Name Description
    IGraph<BidiShape<TOut, TOut2, TIn2, TIn>, TMat2> bidi

    TBD

    Returns
    Type Description
    Flow<TIn2, TOut2, TMat>

    TBD

    Type Parameters
    Name Description
    TIn2

    TBD

    TOut2

    TBD

    TMat2

    TBD

    | Edit this page View Source

    MapMaterializedValue<TMat2>(Func<TMat, TMat2>)

    Transform the materialized value of this Flow, leaving all other properties as they were.

    Declaration
    public Flow<TIn, TOut, TMat2> MapMaterializedValue<TMat2>(Func<TMat, TMat2> mapFunc)
    Parameters
    Type Name Description
    Func<TMat, TMat2> mapFunc

    TBD

    Returns
    Type Description
    Flow<TIn, TOut, TMat2>

    TBD

    Type Parameters
    Name Description
    TMat2

    TBD

    | Edit this page View Source

    Named(string)

    Add a name attribute to this Flow.

    Declaration
    public Flow<TIn, TOut, TMat> Named(string name)
    Parameters
    Type Name Description
    string name

    TBD

    Returns
    Type Description
    Flow<TIn, TOut, TMat>

    TBD

    | Edit this page View Source

    RunWith<TMat1, TMat2>(IGraph<SourceShape<TIn>, TMat1>, IGraph<SinkShape<TOut>, TMat2>, IMaterializer)

    Connect the Source<TOut, TMat> to this Flow<TIn, TOut, TMat> and then connect it to the Sink<TIn, TMat> and run it. The returned tuple contains the materialized values of the source and sink, e.g. the Reactive.Streams.ISubscriber<T> of a AsSubscriber<T>() and Reactive.Streams.IPublisher<T> of a Publisher<TIn>().

    Declaration
    public (TMat1, TMat2) RunWith<TMat1, TMat2>(IGraph<SourceShape<TIn>, TMat1> source, IGraph<SinkShape<TOut>, TMat2> sink, IMaterializer materializer)
    Parameters
    Type Name Description
    IGraph<SourceShape<TIn>, TMat1> source

    TBD

    IGraph<SinkShape<TOut>, TMat2> sink

    TBD

    IMaterializer materializer

    TBD

    Returns
    Type Description
    (TMat1, TMat2)

    TBD

    Type Parameters
    Name Description
    TMat1

    TBD

    TMat2

    TBD

    | Edit this page View Source

    ToMaterialized<TMat2, TMat3>(IGraph<SinkShape<TOut>, TMat2>, Func<TMat, TMat2, TMat3>)

    Connect this Flow<TIn, TOut, TMat> to a Sink<TIn, TMat>, concatenating the processing steps of both. The combine function is used to compose the materialized values of this flow and that Sink into the materialized value of the resulting Sink.

    It is recommended to use the internally optimized Left<TLeft, TRight>(TLeft, TRight) and Right<TLeft, TRight>(TLeft, TRight) combiners where appropriate instead of manually writing functions that pass through one of the values.

    Declaration
    public Sink<TIn, TMat3> ToMaterialized<TMat2, TMat3>(IGraph<SinkShape<TOut>, TMat2> sink, Func<TMat, TMat2, TMat3> combine)
    Parameters
    Type Name Description
    IGraph<SinkShape<TOut>, TMat2> sink

    TBD

    Func<TMat, TMat2, TMat3> combine

    TBD

    Returns
    Type Description
    Sink<TIn, TMat3>

    TBD

    Type Parameters
    Name Description
    TMat2

    TBD

    TMat3

    TBD

    | Edit this page View Source

    ToProcessor()

    Converts this Flow to a IRunnableGraph<TMat> that materializes to a Reactive Streams Reactive.Streams.IProcessor<T1, T2> which implements the operations encapsulated by this Flow. Every materialization results in a new Processor instance, i.e. the returned IRunnableGraph<TMat> is reusable.

    Declaration
    public IRunnableGraph<IProcessor<TIn, TOut>> ToProcessor()
    Returns
    Type Description
    IRunnableGraph<IProcessor<TIn, TOut>>

    A IRunnableGraph<TMat> that materializes to a Reactive.Streams.IProcessor<T1, T2> when Run() is called on it.

    | Edit this page View Source

    ToString()

    TBD

    Declaration
    public override string ToString()
    Returns
    Type Description
    string

    TBD

    Overrides
    object.ToString()
    | Edit this page View Source

    To<TMat2>(IGraph<SinkShape<TOut>, TMat2>)

    Connect this Flow<TIn, TOut, TMat> to a Sink<TIn, TMat>, concatenating the processing steps of both. The materialized value of the combined Sink<TIn, TMat> will be the materialized value of the current flow (ignoring the given Sink’s value), use ToMaterialized<TMat2, TMat3>(IGraph<SinkShape<TOut>, TMat2>, Func<TMat, TMat2, TMat3>) if a different strategy is needed.

    Declaration
    public Sink<TIn, TMat> To<TMat2>(IGraph<SinkShape<TOut>, TMat2> sink)
    Parameters
    Type Name Description
    IGraph<SinkShape<TOut>, TMat2> sink
    Returns
    Type Description
    Sink<TIn, TMat>
    Type Parameters
    Name Description
    TMat2
    | Edit this page View Source

    ViaMaterialized<TOut2, TMat2, TMat3>(IGraph<FlowShape<TOut, TOut2>, TMat2>, Func<TMat, TMat2, TMat3>)

    Transform this Flow<TIn, TOut, TMat> by appending the given processing steps. The combine function is used to compose the materialized values of this flow and that flow into the materialized value of the resulting Flow.

    Declaration
    public Flow<TIn, TOut2, TMat3> ViaMaterialized<TOut2, TMat2, TMat3>(IGraph<FlowShape<TOut, TOut2>, TMat2> flow, Func<TMat, TMat2, TMat3> combine)
    Parameters
    Type Name Description
    IGraph<FlowShape<TOut, TOut2>, TMat2> flow

    TBD

    Func<TMat, TMat2, TMat3> combine

    TBD

    Returns
    Type Description
    Flow<TIn, TOut2, TMat3>

    TBD

    Type Parameters
    Name Description
    TOut2

    TBD

    TMat2

    TBD

    TMat3

    TBD

    | Edit this page View Source

    Via<T2, TMat2>(IGraph<FlowShape<TOut, T2>, TMat2>)

    Transform this Flow<TIn, TOut, TMat> by appending the given processing steps. The materialized value of the combined Flow<TIn, TOut, TMat> will be the materialized value of the current flow (ignoring the other flow’s value), use ViaMaterialized<TOut2, TMat2, TMat3>(IGraph<FlowShape<TOut, TOut2>, TMat2>, Func<TMat, TMat2, TMat3>) if a different strategy is needed.

    Declaration
    public Flow<TIn, T2, TMat> Via<T2, TMat2>(IGraph<FlowShape<TOut, T2>, TMat2> flow)
    Parameters
    Type Name Description
    IGraph<FlowShape<TOut, T2>, TMat2> flow

    TBD

    Returns
    Type Description
    Flow<TIn, T2, TMat>

    TBD

    Type Parameters
    Name Description
    T2

    TBD

    TMat2

    TBD

    | Edit this page View Source

    WithAttributes(Attributes)

    Change the attributes of this Flow<TIn, TOut, TMat> to the given ones. Note that this operation has no effect on an empty Flow (because the attributes apply only to the contained processing stages).

    Declaration
    public Flow<TIn, TOut, TMat> WithAttributes(Attributes attributes)
    Parameters
    Type Name Description
    Attributes attributes

    TBD

    Returns
    Type Description
    Flow<TIn, TOut, TMat>

    TBD

    Implements

    IFlow<TOut, TMat>
    IGraph<TShape, TMaterialized>
    IGraph<TShape>

    Extension Methods

    FlowOperations.AggregateAsync<TIn, TOut1, TOut2, TMat>(Flow<TIn, TOut1, TMat>, TOut2, Func<TOut2, TOut1, Task<TOut2>>)
    FlowOperations.Aggregate<TIn, TOut1, TOut2, TMat>(Flow<TIn, TOut1, TMat>, TOut2, Func<TOut2, TOut1, TOut2>)
    FlowOperations.AlsoToMaterialized<TIn, TOut, TMat, TMat2, TMat3>(Flow<TIn, TOut, TMat>, IGraph<SinkShape<TOut>, TMat2>, Func<TMat, TMat2, TMat3>)
    FlowOperations.AlsoToMaterialized<TIn, TOut, TMat, TMat2, TMat3>(Flow<TIn, TOut, TMat>, IGraph<SinkShape<TOut>, TMat2>, Func<TMat, TMat2, TMat3>, bool)
    FlowOperations.AlsoTo<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, IGraph<SinkShape<TOut>, TMat>)
    FlowOperations.AlsoTo<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, IGraph<SinkShape<TOut>, TMat>, bool)
    FlowOperations.AsFlowWithContext<TIn, TCtxIn, TOut, TCtxOut, TMat, TIn2>(Flow<TIn2, TOut, TMat>, Func<TIn, TCtxIn, TIn2>, Func<TOut, TCtxOut>)
    FlowOperations.BackpressureTimeout<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, TimeSpan)
    FlowOperations.BatchWeighted<TIn, TOut, TOut2, TMat>(Flow<TIn, TOut, TMat>, long, Func<TOut, long>, Func<TOut, TOut2>, Func<TOut2, TOut, TOut2>)
    FlowOperations.Batch<TIn, TOut, TOut2, TMat>(Flow<TIn, TOut, TMat>, long, Func<TOut, TOut2>, Func<TOut2, TOut, TOut2>)
    FlowOperations.Buffer<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, int, OverflowStrategy)
    FlowOperations.Collect<TIn, TOut1, TOut2, TMat>(Flow<TIn, TOut1, TMat>, Func<TOut1, bool>, Func<TOut1, TOut2>)
    FlowOperations.Collect<TIn, TOut1, TOut2, TMat>(Flow<TIn, TOut1, TMat>, Func<TOut1, TOut2>)
    FlowOperations.CompletionTimeout<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, TimeSpan)
    FlowOperations.ConcatMany<TIn, TOut1, TOut2, TMat>(Flow<TIn, TOut1, TMat>, Func<TOut1, IGraph<SourceShape<TOut2>, TMat>>)
    FlowOperations.Concat<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, IGraph<SourceShape<TOut>, TMat>)
    FlowOperations.ConflateWithSeed<TIn, TOut, TMat, TSeed>(Flow<TIn, TOut, TMat>, Func<TOut, TSeed>, Func<TSeed, TOut, TSeed>)
    FlowOperations.Conflate<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, Func<TOut, TOut, TOut>)
    FlowOperations.Delay<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, TimeSpan, DelayOverflowStrategy?)
    FlowOperations.Detach<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>)
    FlowOperations.DivertToMaterialized<TIn, TOut, TMat, TMat2, TMat3>(Flow<TIn, TOut, TMat>, IGraph<SinkShape<TOut>, TMat2>, Func<TOut, bool>, Func<TMat, TMat2, TMat3>)
    FlowOperations.DivertTo<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, IGraph<SinkShape<TOut>, TMat>, Func<TOut, bool>)
    FlowOperations.Expand<TIn, TOut1, TOut2, TMat>(Flow<TIn, TOut1, TMat>, Func<TOut1, IEnumerator<TOut2>>)
    FlowOperations.GroupBy<TIn, TOut, TMat, TKey>(Flow<TIn, TOut, TMat>, Func<TOut, TKey>)
    FlowOperations.GroupBy<TIn, TOut, TMat, TKey>(Flow<TIn, TOut, TMat>, Func<TOut, TKey>, bool)
    FlowOperations.GroupBy<TIn, TOut, TMat, TKey>(Flow<TIn, TOut, TMat>, int, Func<TOut, TKey>)
    FlowOperations.GroupBy<TIn, TOut, TMat, TKey>(Flow<TIn, TOut, TMat>, int, Func<TOut, TKey>, bool)
    FlowOperations.GroupedWeightedWithin<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, long, int, TimeSpan, Func<TOut, long>)
    FlowOperations.GroupedWithin<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, int, TimeSpan)
    FlowOperations.Grouped<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, int)
    FlowOperations.IdleTimeout<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, TimeSpan)
    FlowOperations.InitialDelay<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, TimeSpan)
    FlowOperations.InitialTimeout<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, TimeSpan)
    FlowOperations.InterleaveMaterialized<TIn, T1, T2, TMat, TMat2, TMat3>(Flow<TIn, T1, TMat>, IGraph<SourceShape<T2>, TMat2>, int, Func<TMat, TMat2, TMat3>)
    FlowOperations.Interleave<TIn, T1, T2, TMat>(Flow<TIn, T1, TMat>, IGraph<SourceShape<T2>, TMat>, int)
    FlowOperations.Intersperse<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, TOut)
    FlowOperations.Intersperse<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, TOut, TOut, TOut)
    FlowOperations.KeepAlive<TIn, TOut, TInjected, TMat>(Flow<TIn, TOut, TMat>, TimeSpan, Func<TInjected>)
    FlowOperations.LimitWeighted<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, long, Func<TOut, long>)
    FlowOperations.Limit<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, long)
    FlowOperations.Log<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, string, Func<TOut, object>, ILoggingAdapter, LogLevel)
    FlowOperations.MergeMany<TIn, TOut1, TOut2, TMat>(Flow<TIn, TOut1, TMat>, int, Func<TOut1, IGraph<SourceShape<TOut2>, TMat>>)
    FlowOperations.MergeMaterialized<TIn, TOut1, TOut2, TMat, TMat2, TMat3>(Flow<TIn, TOut1, TMat>, IGraph<SourceShape<TOut2>, TMat2>, Func<TMat, TMat2, TMat3>)
    FlowOperations.MergeSorted<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, IGraph<SourceShape<TOut>, TMat>, IComparer<TOut>)
    FlowOperations.MergeSorted<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, IGraph<SourceShape<TOut>, TMat>, Func<TOut, TOut, int>)
    FlowOperations.Merge<TIn, TOut1, TOut2, TMat>(Flow<TIn, TOut1, TMat>, IGraph<SourceShape<TOut2>, TMat>, bool)
    FlowOperations.Monitor<TIn, TOut, TMat, TMat2>(Flow<TIn, TOut, TMat>, Func<TMat, IFlowMonitor, TMat2>)
    FlowOperations.PrefixAndTail<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, int)
    FlowOperations.Prepend<TIn, TOut1, TOut2, TMat>(Flow<TIn, TOut1, TMat>, IGraph<SourceShape<TOut2>, TMat>)
    FlowOperations.RecoverWithRetries<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, Func<Exception, IGraph<SourceShape<TOut>, TMat>>, int)
    FlowOperations.RecoverWith<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, Func<Exception, IGraph<SourceShape<TOut>, TMat>>)
    FlowOperations.Recover<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, Func<Exception, Option<TOut>>)
    FlowOperations.RepeatPrevious<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>)
    FlowOperations.RepeatPrevious<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, Action<TOut, TOut>)
    FlowOperations.ScanAsync<TIn, TOut1, TOut2, TMat>(Flow<TIn, TOut1, TMat>, TOut2, Func<TOut2, TOut1, Task<TOut2>>)
    FlowOperations.Scan<TIn, TOut1, TOut2, TMat>(Flow<TIn, TOut1, TMat>, TOut2, Func<TOut2, TOut1, TOut2>)
    FlowOperations.SelectAsyncUnordered<T, TIn, TOut, TMat>(Flow<T, TIn, TMat>, int, Func<TIn, Task<TOut>>)
    FlowOperations.SelectAsync<T, TIn, TOut, TMat>(Flow<T, TIn, TMat>, int, Func<TIn, Task<TOut>>)
    FlowOperations.SelectError<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, Func<Exception, Exception>)
    FlowOperations.SelectMany<T, TIn, TOut, TMat>(Flow<T, TIn, TMat>, Func<TIn, IEnumerable<TOut>>)
    FlowOperations.Select<T, TIn, TOut, TMat>(Flow<T, TIn, TMat>, Func<TIn, TOut>)
    FlowOperations.SkipWhile<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, Predicate<TOut>)
    FlowOperations.SkipWithin<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, TimeSpan)
    FlowOperations.Skip<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, long)
    FlowOperations.Sliding<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, int, int)
    FlowOperations.SplitAfter<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, SubstreamCancelStrategy, Func<TOut, bool>)
    FlowOperations.SplitAfter<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, Func<TOut, bool>)
    FlowOperations.SplitWhen<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, SubstreamCancelStrategy, Func<TOut, bool>)
    FlowOperations.SplitWhen<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, Func<TOut, bool>)
    FlowOperations.StatefulSelectMany<T, TIn, TOut, TMat>(Flow<T, TIn, TMat>, Func<Func<TIn, IEnumerable<TOut>>>)
    FlowOperations.Sum<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, Func<TOut, TOut, TOut>)
    FlowOperations.TakeWhile<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, Predicate<TOut>, bool)
    FlowOperations.TakeWithin<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, TimeSpan)
    FlowOperations.Take<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, long)
    FlowOperations.Throttle<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, int, TimeSpan, int, ThrottleMode)
    FlowOperations.Throttle<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, int, TimeSpan, int, Func<TOut, int>, ThrottleMode)
    FlowOperations.Transform<TIn, TOut1, TOut2, TMat>(Flow<TIn, TOut1, TMat>, Func<IStage<TOut1, TOut2>>)
    FlowOperations.WatchTermination<TIn, TOut, TMat, TMat2>(Flow<TIn, TOut, TMat>, Func<TMat, Task<Done>, TMat2>)
    FlowOperations.WhereNot<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, Predicate<TOut>)
    FlowOperations.Where<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, Predicate<TOut>)
    FlowOperations.WireTapMaterialized<TIn, TOut, TMat, TMat2, TMat3>(Flow<TIn, TOut, TMat>, IGraph<SinkShape<TOut>, TMat2>, Func<TMat, TMat2, TMat3>)
    FlowOperations.WireTap<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, IGraph<SinkShape<TOut>, TMat>)
    FlowOperations.WireTap<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, Action<TOut>)
    FlowOperations.ZipWithIndex<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>)
    FlowOperations.ZipWith<TIn, T1, T2, T3, TMat>(Flow<TIn, T1, TMat>, IGraph<SourceShape<T2>, TMat>, Func<T1, T2, T3>)
    FlowOperations.Zip<TIn, T1, T2, TMat>(Flow<TIn, T1, TMat>, IGraph<SourceShape<T2>, TMat>)
    TimedFlowDsl.TimedIntervalBetween<TIn, TOut, TMat>(Flow<TIn, TOut, TMat>, Func<TOut, bool>, Action<TimeSpan>)
    TimedFlowDsl.Timed<TIn, TOut, TOut2, TMat, TMat2>(Flow<TIn, TOut, TMat>, Func<Flow<TIn, TOut, TMat>, Flow<TIn, TOut2, TMat2>>, Action<TimeSpan>)
    ObjectExtensions.IsDefaultForType<T>(T)
    ObjectExtensions.AsOption<T>(T)
    Extensions.AsInstanceOf<T>(object)
    In this article
    • githubEdit this page
    • View Source
    Back to top
    Contribute
    • Project Chat
    • Discussion Forum
    • Source Code
    Support
    • Akka.NET Support Plans
    • Akka.NET Observability Tools
    • Akka.NET Training & Consulting
    Maintained By
    • Petabridge - The Akka.NET Company
    • Learn Akka.NET