Search Results for

    Show / Hide Table of Contents

    Class Source<TOut, TMat>

    A Source<TOut, TMat> is a set of stream processing steps that has one open output. It can comprise any number of internal sources and transformations that are wired together, or it can be an "atomic" source, e.g. from a collection or a file. Materialization turns a Source into a Reactive Streams Reactive.Streams.IPublisher<T> (at least conceptually).

    Inheritance
    object
    Source<TOut, TMat>
    Implements
    IFlow<TOut, TMat>
    IGraph<SourceShape<TOut>, TMat>
    IGraph<SourceShape<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 Source<TOut, TMat> : IFlow<TOut, TMat>, IGraph<SourceShape<TOut>, TMat>, IGraph<SourceShape<TOut>>
    Type Parameters
    Name Description
    TOut

    TBD

    TMat

    TBD

    Constructors

    | Edit this page View Source

    Source(IModule)

    TBD

    Declaration
    public Source(IModule module)
    Parameters
    Type Name Description
    IModule module

    TBD

    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 SourceShape<TOut> Shape { get; }
    Property Value
    Type Description
    SourceShape<TOut>

    Methods

    | Edit this page View Source

    AddAttributes(Attributes)

    Add the given attributes to this Source<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 Source<TOut, TMat> AddAttributes(Attributes attributes)
    Parameters
    Type Name Description
    Attributes attributes

    TBD

    Returns
    Type Description
    Source<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 Source<TOut2, TMat> Ask<TOut2>(IActorRef actorRef, TimeSpan timeout, int parallelism = 2)
    Parameters
    Type Name Description
    IActorRef actorRef
    TimeSpan timeout
    int parallelism
    Returns
    Type Description
    Source<TOut2, TMat>
    Type Parameters
    Name Description
    TOut2
    | Edit this page View Source

    Async()

    Put an asynchronous boundary around this Source.

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

    TBD

    | Edit this page View Source

    Combine<T, TOut2>(Source<T, NotUsed>, Source<T, NotUsed>, Func<int, IGraph<UniformFanInShape<T, TOut2>, NotUsed>>, params Source<T, NotUsed>[])

    Combines several sources with fun-in strategy like Merge<TIn, TOut> or Concat<TIn, TOut> and returns Source<TOut, TMat>.

    Declaration
    public Source<TOut2, NotUsed> Combine<T, TOut2>(Source<T, NotUsed> first, Source<T, NotUsed> second, Func<int, IGraph<UniformFanInShape<T, TOut2>, NotUsed>> strategy, params Source<T, NotUsed>[] rest)
    Parameters
    Type Name Description
    Source<T, NotUsed> first

    TBD

    Source<T, NotUsed> second

    TBD

    Func<int, IGraph<UniformFanInShape<T, TOut2>, NotUsed>> strategy

    TBD

    Source<T, NotUsed>[] rest

    TBD

    Returns
    Type Description
    Source<TOut2, NotUsed>

    TBD

    Type Parameters
    Name Description
    T

    TBD

    TOut2

    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 Source<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
    Source<TOut, TMat3>

    TBD

    Type Parameters
    Name Description
    TMat2

    TBD

    TMat3

    TBD

    | Edit this page View Source

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

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

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

    TBD

    Returns
    Type Description
    Source<TOut, TMat2>

    TBD

    Type Parameters
    Name Description
    TMat2

    TBD

    | Edit this page View Source

    Named(string)

    Add a name attribute to this Source.

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

    TBD

    Returns
    Type Description
    Source<TOut, TMat>

    TBD

    | Edit this page View Source

    PreMaterialize(ActorSystem)

    Materializes this Source immediately.

    Declaration
    public (TMat, Source<TOut, NotUsed>) PreMaterialize(ActorSystem actorSystem)
    Parameters
    Type Name Description
    ActorSystem actorSystem

    The ActorSystem.

    Returns
    Type Description
    (TMat, Source<TOut, NotUsed>)

    A tuple containing the (1) materialized value and (2) a new Source that can be used to consume elements from the newly materialized Source.

    | Edit this page View Source

    PreMaterialize(IMaterializer)

    Materializes this Source immediately.

    Declaration
    public (TMat, Source<TOut, NotUsed>) PreMaterialize(IMaterializer materializer)
    Parameters
    Type Name Description
    IMaterializer materializer

    The materializer.

    Returns
    Type Description
    (TMat, Source<TOut, NotUsed>)

    A tuple containing the (1) materialized value and (2) a new Source that can be used to consume elements from the newly materialized Source.

    | Edit this page View Source

    RunAggregateAsync<TOut2>(TOut2, Func<TOut2, TOut, Task<TOut2>>, ActorSystem)

    Shortcut for running this Source<TOut, TMat> with a async aggregate function. The given function is invoked for every received element, giving it its previous output (or the given zero value) and the element as input. The returned Task<TResult> will be completed with value of the final function evaluation when the input stream ends, or completed with Failure if there is a failure signaled in the stream.

    Declaration
    public Task<TOut2> RunAggregateAsync<TOut2>(TOut2 zero, Func<TOut2, TOut, Task<TOut2>> aggregate, ActorSystem materializer)
    Parameters
    Type Name Description
    TOut2 zero

    TBD

    Func<TOut2, TOut, Task<TOut2>> aggregate

    TBD

    ActorSystem materializer

    TBD

    Returns
    Type Description
    Task<TOut2>

    TBD

    Type Parameters
    Name Description
    TOut2

    TBD

    | Edit this page View Source

    RunAggregateAsync<TOut2>(TOut2, Func<TOut2, TOut, Task<TOut2>>, IMaterializer)

    Shortcut for running this Source<TOut, TMat> with a async aggregate function. The given function is invoked for every received element, giving it its previous output (or the given zero value) and the element as input. The returned Task<TResult> will be completed with value of the final function evaluation when the input stream ends, or completed with Failure if there is a failure signaled in the stream.

    Declaration
    public Task<TOut2> RunAggregateAsync<TOut2>(TOut2 zero, Func<TOut2, TOut, Task<TOut2>> aggregate, IMaterializer materializer)
    Parameters
    Type Name Description
    TOut2 zero

    TBD

    Func<TOut2, TOut, Task<TOut2>> aggregate

    TBD

    IMaterializer materializer

    TBD

    Returns
    Type Description
    Task<TOut2>

    TBD

    Type Parameters
    Name Description
    TOut2

    TBD

    | Edit this page View Source

    RunAggregate<TOut2>(TOut2, Func<TOut2, TOut, TOut2>, ActorSystem)

    Shortcut for running this Source<TOut, TMat> with a fold function. The given function is invoked for every received element, giving it its previous output (or the given zero value) and the element as input. The returned Task<TResult> will be completed with value of the final function evaluation when the input stream ends, or completed with Failure if there is a failure signaled in the stream.

    Declaration
    public Task<TOut2> RunAggregate<TOut2>(TOut2 zero, Func<TOut2, TOut, TOut2> aggregate, ActorSystem materializer)
    Parameters
    Type Name Description
    TOut2 zero

    TBD

    Func<TOut2, TOut, TOut2> aggregate

    TBD

    ActorSystem materializer

    TBD

    Returns
    Type Description
    Task<TOut2>

    TBD

    Type Parameters
    Name Description
    TOut2

    TBD

    | Edit this page View Source

    RunAggregate<TOut2>(TOut2, Func<TOut2, TOut, TOut2>, IMaterializer)

    Shortcut for running this Source<TOut, TMat> with a fold function. The given function is invoked for every received element, giving it its previous output (or the given zero value) and the element as input. The returned Task<TResult> will be completed with value of the final function evaluation when the input stream ends, or completed with Failure if there is a failure signaled in the stream.

    Declaration
    public Task<TOut2> RunAggregate<TOut2>(TOut2 zero, Func<TOut2, TOut, TOut2> aggregate, IMaterializer materializer)
    Parameters
    Type Name Description
    TOut2 zero

    TBD

    Func<TOut2, TOut, TOut2> aggregate

    TBD

    IMaterializer materializer

    TBD

    Returns
    Type Description
    Task<TOut2>

    TBD

    Type Parameters
    Name Description
    TOut2

    TBD

    | Edit this page View Source

    RunAsAsyncEnumerable(ActorSystem)

    Shortcut for running this Source<TOut, TMat> as an IAsyncEnumerable<T>. The given enumerable is re-runnable but will cause a re-materialization of the stream each time. This is implemented using a SourceQueue and will buffer elements based on configured stream defaults. For custom buffers Please use RunAsAsyncEnumerableBuffer(IMaterializer, int, int)

    Declaration
    public IAsyncEnumerable<TOut> RunAsAsyncEnumerable(ActorSystem materializer)
    Parameters
    Type Name Description
    ActorSystem materializer

    The materializer to use for each enumeration

    Returns
    Type Description
    IAsyncEnumerable<TOut>

    A lazy IAsyncEnumerable<T> that will run each time it is enumerated.

    | Edit this page View Source

    RunAsAsyncEnumerable(IMaterializer)

    Shortcut for running this Source<TOut, TMat> as an IAsyncEnumerable<T>. The given enumerable is re-runnable but will cause a re-materialization of the stream each time. This is implemented using a SourceQueue and will buffer elements based on configured stream defaults. For custom buffers Please use RunAsAsyncEnumerableBuffer(IMaterializer, int, int)

    Declaration
    public IAsyncEnumerable<TOut> RunAsAsyncEnumerable(IMaterializer materializer)
    Parameters
    Type Name Description
    IMaterializer materializer

    The materializer to use for each enumeration

    Returns
    Type Description
    IAsyncEnumerable<TOut>

    A lazy IAsyncEnumerable<T> that will run each time it is enumerated.

    | Edit this page View Source

    RunAsAsyncEnumerableBuffer(ActorSystem, int, int)

    Shortcut for running this Source<TOut, TMat> as an IAsyncEnumerable<T>. The given enumerable is re-runnable but will cause a re-materialization of the stream each time. This is implemented using a SourceQueue and will buffer elements and/or backpressure, based on the buffer values provided.

    Declaration
    public IAsyncEnumerable<TOut> RunAsAsyncEnumerableBuffer(ActorSystem materializer, int minBuffer = 4, int maxBuffer = 16)
    Parameters
    Type Name Description
    ActorSystem materializer

    The materializer to use for each enumeration

    int minBuffer

    The minimum input buffer size

    int maxBuffer

    The Max input buffer size.

    Returns
    Type Description
    IAsyncEnumerable<TOut>

    A lazy IAsyncEnumerable<T> that will run each time it is enumerated.

    | Edit this page View Source

    RunAsAsyncEnumerableBuffer(IMaterializer, int, int)

    Shortcut for running this Source<TOut, TMat> as an IAsyncEnumerable<T>. The given enumerable is re-runnable but will cause a re-materialization of the stream each time. This is implemented using a SourceQueue and will buffer elements and/or backpressure, based on the buffer values provided.

    Declaration
    public IAsyncEnumerable<TOut> RunAsAsyncEnumerableBuffer(IMaterializer materializer, int minBuffer = 4, int maxBuffer = 16)
    Parameters
    Type Name Description
    IMaterializer materializer

    The materializer to use for each enumeration

    int minBuffer

    The minimum input buffer size

    int maxBuffer

    The Max input buffer size.

    Returns
    Type Description
    IAsyncEnumerable<TOut>

    A lazy IAsyncEnumerable<T> that will run each time it is enumerated.

    | Edit this page View Source

    RunForeach(Action<TOut>, ActorSystem)

    Shortcut for running this Source<TOut, TMat> with a foreach procedure. The given procedure is invoked for each received element. The returned Task will be completed with Success when reaching the normal end of the stream, or completed with Failure if there is a failure signaled in the stream.

    Declaration
    public Task RunForeach(Action<TOut> action, ActorSystem materializer)
    Parameters
    Type Name Description
    Action<TOut> action

    TBD

    ActorSystem materializer

    TBD

    Returns
    Type Description
    Task

    TBD

    | Edit this page View Source

    RunForeach(Action<TOut>, IMaterializer)

    Shortcut for running this Source<TOut, TMat> with a foreach procedure. The given procedure is invoked for each received element. The returned Task will be completed with Success when reaching the normal end of the stream, or completed with Failure if there is a failure signaled in the stream.

    Declaration
    public Task RunForeach(Action<TOut> action, IMaterializer materializer)
    Parameters
    Type Name Description
    Action<TOut> action

    TBD

    IMaterializer materializer

    TBD

    Returns
    Type Description
    Task

    TBD

    | Edit this page View Source

    RunSum(Func<TOut, TOut, TOut>, ActorSystem)

    Shortcut for running this Source<TOut, TMat> with a reduce function. The given function is invoked for every received element, giving it its previous output (from the second element) and the element as input. The returned Task<TResult> will be completed with value of the final function evaluation when the input stream ends, or completed with Failure if there is a failure signaled in the stream.

    Declaration
    public Task<TOut> RunSum(Func<TOut, TOut, TOut> reduce, ActorSystem materializer)
    Parameters
    Type Name Description
    Func<TOut, TOut, TOut> reduce

    TBD

    ActorSystem materializer

    TBD

    Returns
    Type Description
    Task<TOut>

    TBD

    | Edit this page View Source

    RunSum(Func<TOut, TOut, TOut>, IMaterializer)

    Shortcut for running this Source<TOut, TMat> with a reduce function. The given function is invoked for every received element, giving it its previous output (from the second element) and the element as input. The returned Task<TResult> will be completed with value of the final function evaluation when the input stream ends, or completed with Failure if there is a failure signaled in the stream.

    Declaration
    public Task<TOut> RunSum(Func<TOut, TOut, TOut> reduce, IMaterializer materializer)
    Parameters
    Type Name Description
    Func<TOut, TOut, TOut> reduce

    TBD

    IMaterializer materializer

    TBD

    Returns
    Type Description
    Task<TOut>

    TBD

    | Edit this page View Source

    RunWith<TMat2>(IGraph<SinkShape<TOut>, TMat2>, ActorSystem)

    Connect this Source<TOut, TMat> to a Sink<TIn, TMat> and run it. The returned value is the materialized value of the Sink<TIn, TMat> , e.g. the Reactive.Streams.IPublisher<T> of a Publisher<TIn>().

    Declaration
    public TMat2 RunWith<TMat2>(IGraph<SinkShape<TOut>, TMat2> sink, ActorSystem materializer)
    Parameters
    Type Name Description
    IGraph<SinkShape<TOut>, TMat2> sink

    TBD

    ActorSystem materializer

    TBD

    Returns
    Type Description
    TMat2

    TBD

    Type Parameters
    Name Description
    TMat2

    TBD

    | Edit this page View Source

    RunWith<TMat2>(IGraph<SinkShape<TOut>, TMat2>, IMaterializer)

    Connect this Source<TOut, TMat> to a Sink<TIn, TMat> and run it. The returned value is the materialized value of the Sink<TIn, TMat> , e.g. the Reactive.Streams.IPublisher<T> of a Publisher<TIn>().

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

    TBD

    IMaterializer materializer

    TBD

    Returns
    Type Description
    TMat2

    TBD

    Type Parameters
    Name Description
    TMat2

    TBD

    | Edit this page View Source

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

    Connect this Source<TOut, TMat> to a Sink<TIn, TMat>, concatenating the processing steps of both.

    Declaration
    public IRunnableGraph<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
    IRunnableGraph<TMat3>

    TBD

    Type Parameters
    Name Description
    TMat2

    TBD

    TMat3

    TBD

    | 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 Source<TOut, TMat> to a Sink<TIn, TMat>, concatenating the processing steps of both.

    Declaration
    public IRunnableGraph<TMat> To<TMat2>(IGraph<SinkShape<TOut>, TMat2> sink)
    Parameters
    Type Name Description
    IGraph<SinkShape<TOut>, TMat2> sink

    TBD

    Returns
    Type Description
    IRunnableGraph<TMat>

    TBD

    Type Parameters
    Name Description
    TMat2

    TBD

    | Edit this page View Source

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

    Transform this Source<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 Source<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
    Source<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 Source<TOut, TMat> by appending the given processing steps. The materialized value of the combined Source<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 Source<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
    Source<T2, TMat>

    TBD

    Type Parameters
    Name Description
    T2

    TBD

    TMat2

    TBD

    | Edit this page View Source

    WithAttributes(Attributes)

    Nests the current Source and returns a Source with the given Attributes

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

    The attributes to add

    Returns
    Type Description
    Source<TOut, TMat>

    A new Source with the added attributes

    | Edit this page View Source

    ZipN<T>(IEnumerable<Source<T, NotUsed>>)

    Combine the elements of multiple streams into a stream of lists.

    Declaration
    public Source<IImmutableList<T>, NotUsed> ZipN<T>(IEnumerable<Source<T, NotUsed>> sources)
    Parameters
    Type Name Description
    IEnumerable<Source<T, NotUsed>> sources

    TBD

    Returns
    Type Description
    Source<IImmutableList<T>, NotUsed>

    TBD

    Type Parameters
    Name Description
    T

    TBD

    | Edit this page View Source

    ZipWithN<T, TOut2>(Func<IImmutableList<T>, TOut2>, IEnumerable<Source<T, NotUsed>>)

    Combine the elements of multiple streams into a stream of sequences using a combiner function.

    Declaration
    public Source<TOut2, NotUsed> ZipWithN<T, TOut2>(Func<IImmutableList<T>, TOut2> zipper, IEnumerable<Source<T, NotUsed>> sources)
    Parameters
    Type Name Description
    Func<IImmutableList<T>, TOut2> zipper

    TBD

    IEnumerable<Source<T, NotUsed>> sources

    TBD

    Returns
    Type Description
    Source<TOut2, NotUsed>

    TBD

    Type Parameters
    Name Description
    T

    TBD

    TOut2

    TBD

    Implements

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

    Extension Methods

    SourceOperations.AggregateAsync<TOut1, TOut2, TMat>(Source<TOut1, TMat>, TOut2, Func<TOut2, TOut1, Task<TOut2>>)
    SourceOperations.Aggregate<TOut1, TOut2, TMat>(Source<TOut1, TMat>, TOut2, Func<TOut2, TOut1, TOut2>)
    SourceOperations.AlsoToMaterialized<TOut, TMat, TMat2, TMat3>(Source<TOut, TMat>, IGraph<SinkShape<TOut>, TMat2>, Func<TMat, TMat2, TMat3>)
    SourceOperations.AlsoToMaterialized<TOut, TMat, TMat2, TMat3>(Source<TOut, TMat>, IGraph<SinkShape<TOut>, TMat2>, Func<TMat, TMat2, TMat3>, bool)
    SourceOperations.AlsoTo<TOut, TMat>(Source<TOut, TMat>, IGraph<SinkShape<TOut>, TMat>)
    SourceOperations.AlsoTo<TOut, TMat>(Source<TOut, TMat>, IGraph<SinkShape<TOut>, TMat>, bool)
    SourceOperations.AsSourceWithContext<TOut, TCtx, TMat>(Source<TOut, TMat>, Func<TOut, TCtx>)
    SourceOperations.BackpressureTimeout<TOut, TMat>(Source<TOut, TMat>, TimeSpan)
    SourceOperations.BatchWeighted<TOut, TOut2, TMat>(Source<TOut, TMat>, long, Func<TOut, long>, Func<TOut, TOut2>, Func<TOut2, TOut, TOut2>)
    SourceOperations.Batch<TOut, TOut2, TMat>(Source<TOut, TMat>, long, Func<TOut, TOut2>, Func<TOut2, TOut, TOut2>)
    SourceOperations.Buffer<TOut, TMat>(Source<TOut, TMat>, int, OverflowStrategy)
    SourceOperations.Collect<TOut1, TOut2, TMat>(Source<TOut1, TMat>, Func<TOut1, bool>, Func<TOut1, TOut2>)
    SourceOperations.Collect<TOut1, TOut2, TMat>(Source<TOut1, TMat>, Func<TOut1, TOut2>)
    SourceOperations.CombineMaterialized<T, TOut2, TMat1, TMat2, TMatOut>(Source<T, TMat1>, Source<T, TMat2>, Func<int, IGraph<UniformFanInShape<T, TOut2>, NotUsed>>, Func<TMat1, TMat2, TMatOut>)
    SourceOperations.CompletionTimeout<TOut, TMat>(Source<TOut, TMat>, TimeSpan)
    SourceOperations.ConcatMany<TOut1, TOut2, TMat>(Source<TOut1, TMat>, Func<TOut1, IGraph<SourceShape<TOut2>, TMat>>)
    SourceOperations.Concat<TOut, TMat>(Source<TOut, TMat>, IGraph<SourceShape<TOut>, TMat>)
    SourceOperations.ConflateWithSeed<TOut, TMat, TSeed>(Source<TOut, TMat>, Func<TOut, TSeed>, Func<TSeed, TOut, TSeed>)
    SourceOperations.Conflate<TOut, TMat>(Source<TOut, TMat>, Func<TOut, TOut, TOut>)
    SourceOperations.Delay<TOut, TMat>(Source<TOut, TMat>, TimeSpan, DelayOverflowStrategy?)
    SourceOperations.Detach<TOut, TMat>(Source<TOut, TMat>)
    SourceOperations.DivertToMaterialized<TOut, TMat, TMat2, TMat3>(Source<TOut, TMat>, IGraph<SinkShape<TOut>, TMat2>, Func<TOut, bool>, Func<TMat, TMat2, TMat3>)
    SourceOperations.DivertTo<TOut, TMat>(Source<TOut, TMat>, IGraph<SinkShape<TOut>, TMat>, Func<TOut, bool>)
    SourceOperations.Expand<TOut1, TOut2, TMat>(Source<TOut1, TMat>, Func<TOut1, IEnumerator<TOut2>>)
    SourceOperations.GroupBy<TOut, TMat, TKey>(Source<TOut, TMat>, Func<TOut, TKey>)
    SourceOperations.GroupBy<TOut, TMat, TKey>(Source<TOut, TMat>, int, Func<TOut, TKey>)
    SourceOperations.GroupedWeightedWithin<TOut, TMat>(Source<TOut, TMat>, long, int, TimeSpan, Func<TOut, long>)
    SourceOperations.GroupedWeightedWithin<TOut, TMat>(Source<TOut, TMat>, long, TimeSpan, Func<TOut, long>)
    SourceOperations.GroupedWithin<TOut, TMat>(Source<TOut, TMat>, int, TimeSpan)
    SourceOperations.Grouped<TOut, TMat>(Source<TOut, TMat>, int)
    SourceOperations.IdleTimeout<TOut, TMat>(Source<TOut, TMat>, TimeSpan)
    SourceOperations.InitialDelay<TOut, TMat>(Source<TOut, TMat>, TimeSpan)
    SourceOperations.InitialTimeout<TOut, TMat>(Source<TOut, TMat>, TimeSpan)
    SourceOperations.InterleaveMaterialized<T1, T2, TMat, TMat2, TMat3>(Source<T1, TMat>, IGraph<SourceShape<T2>, TMat2>, int, Func<TMat, TMat2, TMat3>)
    SourceOperations.Interleave<T1, T2, TMat>(Source<T1, TMat>, IGraph<SourceShape<T2>, TMat>, int)
    SourceOperations.Intersperse<TOut, TMat>(Source<TOut, TMat>, TOut)
    SourceOperations.Intersperse<TOut, TMat>(Source<TOut, TMat>, TOut, TOut, TOut)
    SourceOperations.KeepAlive<TOut, TInjected, TMat>(Source<TOut, TMat>, TimeSpan, Func<TInjected>)
    SourceOperations.LimitWeighted<T, TMat>(Source<T, TMat>, long, Func<T, long>)
    SourceOperations.Limit<T, TMat>(Source<T, TMat>, long)
    SourceOperations.Log<TOut, TMat>(Source<TOut, TMat>, string, Func<TOut, object>, ILoggingAdapter, LogLevel)
    SourceOperations.MergeMany<TOut1, TOut2, TMat>(Source<TOut1, TMat>, int, Func<TOut1, IGraph<SourceShape<TOut2>, TMat>>)
    SourceOperations.MergeMaterialized<TOut1, TOut2, TMat, TMat2, TMat3>(Source<TOut1, TMat>, IGraph<SourceShape<TOut2>, TMat2>, Func<TMat, TMat2, TMat3>)
    SourceOperations.MergeSorted<TOut, TMat>(Source<TOut, TMat>, IGraph<SourceShape<TOut>, TMat>, IComparer<TOut>)
    SourceOperations.MergeSorted<TOut, TMat>(Source<TOut, TMat>, IGraph<SourceShape<TOut>, TMat>, Func<TOut, TOut, int>)
    SourceOperations.Merge<TOut1, TOut2, TMat>(Source<TOut1, TMat>, IGraph<SourceShape<TOut2>, TMat>, bool)
    SourceOperations.Monitor<TOut, TMat, TMat2>(Source<TOut, TMat>, Func<TMat, IFlowMonitor, TMat2>)
    SourceOperations.OrElseMaterialized<T, TMat, TMat2, TMat3>(Source<T, TMat>, IGraph<SourceShape<T>, TMat2>, Func<TMat, TMat2, TMat3>)
    SourceOperations.OrElse<T, TMat>(Source<T, TMat>, IGraph<SourceShape<T>, TMat>)
    SourceOperations.PrefixAndTail<TOut, TMat>(Source<TOut, TMat>, int)
    SourceOperations.Prepend<TOut1, TOut2, TMat>(Source<TOut1, TMat>, IGraph<SourceShape<TOut2>, TMat>)
    SourceOperations.RecoverWithRetries<TOut, TMat>(Source<TOut, TMat>, Func<Exception, IGraph<SourceShape<TOut>, TMat>>, int)
    SourceOperations.RecoverWith<TOut, TMat>(Source<TOut, TMat>, Func<Exception, IGraph<SourceShape<TOut>, TMat>>)
    SourceOperations.Recover<TOut, TMat>(Source<TOut, TMat>, Func<Exception, Option<TOut>>)
    SourceOperations.RepeatPrevious<T, TMat>(Source<T, TMat>)
    SourceOperations.RepeatPrevious<T, TMat>(Source<T, TMat>, Action<T, T>)
    SourceOperations.ScanAsync<TOut1, TOut2, TMat>(Source<TOut1, TMat>, TOut2, Func<TOut2, TOut1, Task<TOut2>>)
    SourceOperations.Scan<TOut1, TOut2, TMat>(Source<TOut1, TMat>, TOut2, Func<TOut2, TOut1, TOut2>)
    SourceOperations.SelectAsyncUnordered<TIn, TOut, TMat>(Source<TIn, TMat>, int, Func<TIn, Task<TOut>>)
    SourceOperations.SelectAsync<TIn, TOut, TMat>(Source<TIn, TMat>, int, Func<TIn, Task<TOut>>)
    SourceOperations.SelectError<TOut, TMat>(Source<TOut, TMat>, Func<Exception, Exception>)
    SourceOperations.SelectMany<TOut1, TOut2, TMat>(Source<TOut1, TMat>, Func<TOut1, IEnumerable<TOut2>>)
    SourceOperations.Select<TIn, TOut, TMat>(Source<TIn, TMat>, Func<TIn, TOut>)
    SourceOperations.SkipWhile<TOut, TMat>(Source<TOut, TMat>, Predicate<TOut>)
    SourceOperations.SkipWithin<TOut, TMat>(Source<TOut, TMat>, TimeSpan)
    SourceOperations.Skip<TOut, TMat>(Source<TOut, TMat>, long)
    SourceOperations.Sliding<TOut, TMat>(Source<TOut, TMat>, int, int)
    SourceOperations.SplitAfter<TOut, TMat>(Source<TOut, TMat>, SubstreamCancelStrategy, Func<TOut, bool>)
    SourceOperations.SplitAfter<TOut, TMat>(Source<TOut, TMat>, Func<TOut, bool>)
    SourceOperations.SplitWhen<TOut, TMat>(Source<TOut, TMat>, SubstreamCancelStrategy, Func<TOut, bool>)
    SourceOperations.SplitWhen<TOut, TMat>(Source<TOut, TMat>, Func<TOut, bool>)
    SourceOperations.StatefulSelectMany<TOut1, TOut2, TMat>(Source<TOut1, TMat>, Func<Func<TOut1, IEnumerable<TOut2>>>)
    SourceOperations.Sum<TOut, TMat>(Source<TOut, TMat>, Func<TOut, TOut, TOut>)
    SourceOperations.TakeWhile<TOut, TMat>(Source<TOut, TMat>, Predicate<TOut>, bool)
    SourceOperations.TakeWithin<TOut, TMat>(Source<TOut, TMat>, TimeSpan)
    SourceOperations.Take<TOut, TMat>(Source<TOut, TMat>, long)
    SourceOperations.Throttle<TOut, TMat>(Source<TOut, TMat>, int, TimeSpan, int, ThrottleMode)
    SourceOperations.Throttle<TOut, TMat>(Source<TOut, TMat>, int, TimeSpan, int, Func<TOut, int>, ThrottleMode)
    SourceOperations.Transform<TOut1, TOut2, TMat>(Source<TOut1, TMat>, Func<IStage<TOut1, TOut2>>)
    SourceOperations.WatchTermination<TOut, TMat, TMat2>(Source<TOut, TMat>, Func<TMat, Task<Done>, TMat2>)
    SourceOperations.Watch<T, TMat>(Source<T, TMat>, IActorRef)
    SourceOperations.WhereNot<TOut, TMat>(Source<TOut, TMat>, Predicate<TOut>)
    SourceOperations.Where<TOut, TMat>(Source<TOut, TMat>, Predicate<TOut>)
    SourceOperations.WireTapMaterialized<TOut, TMat, TMat2, TMat3>(Source<TOut, TMat>, IGraph<SinkShape<TOut>, TMat2>, Func<TMat, TMat2, TMat3>)
    SourceOperations.WireTap<TOut, TMat>(Source<TOut, TMat>, IGraph<SinkShape<TOut>, TMat>)
    SourceOperations.WireTap<TOut, TMat>(Source<TOut, TMat>, Action<TOut>)
    SourceOperations.ZipWithIndex<TOut1, TMat>(Source<TOut1, TMat>)
    SourceOperations.ZipWith<T1, T2, T3, TMat>(Source<T1, TMat>, IGraph<SourceShape<T2>, TMat>, Func<T1, T2, T3>)
    SourceOperations.Zip<T1, T2, TMat>(Source<T1, TMat>, IGraph<SourceShape<T2>, TMat>)
    TimedSourceDsl.TimedIntervalBetween<TIn, TMat>(Source<TIn, TMat>, Func<TIn, bool>, Action<TimeSpan>)
    TimedSourceDsl.Timed<TIn, TOut, TMat, TMat2>(Source<TIn, TMat>, Func<Source<TIn, TMat>, Source<TOut, 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