public interface FlowOps<Out,Mat>
INTERNAL API: this trait will be changed in binary-incompatible ways for classes that are derived from it! Do not implement this interface outside the Akka code base!
Binary compatibility is only maintained for callers of this trait’s interface.
Modifier and Type | Method and Description |
---|---|
FlowOps |
addAttributes(Attributes attr) |
FlowOps |
alsoTo(Graph<SinkShape<Out>,?> that)
|
<M> Graph<FlowShape<Out,Out>,M> |
alsoToGraph(Graph<SinkShape<Out>,M> that) |
<T> FlowOps |
andThen(Stages.SymbolicStage<Out,T> op)
INTERNAL API
|
FlowOps |
async()
Put an asynchronous boundary around this
Flow . |
FlowOps |
backpressureTimeout(scala.concurrent.duration.FiniteDuration timeout)
If the time between the emission of an element and the following downstream demand exceeds the provided timeout,
the stream is failed with a
scala.concurrent.TimeoutException . |
<S> FlowOps |
batch(long max,
scala.Function1<Out,S> seed,
scala.Function2<S,Out,S> aggregate)
Allows a faster upstream to progress independently of a slower subscriber by aggregating elements into batches
until the subscriber is ready to accept them.
|
<S> FlowOps |
batchWeighted(long max,
scala.Function1<Out,java.lang.Object> costFn,
scala.Function1<Out,S> seed,
scala.Function2<S,Out,S> aggregate)
Allows a faster upstream to progress independently of a slower subscriber by aggregating elements into batches
until the subscriber is ready to accept them.
|
FlowOps |
buffer(int size,
OverflowStrategy overflowStrategy)
Adds a fixed size buffer in the flow that allows to store elements from a faster upstream until it becomes full.
|
<T> FlowOps |
collect(scala.PartialFunction<Out,T> pf)
Transform this stream by applying the given partial function to each of the elements
on which the function is defined as they pass through this processing step.
|
FlowOps |
completionTimeout(scala.concurrent.duration.FiniteDuration timeout)
If the completion of the stream does not happen until the provided timeout, the stream is failed
with a
scala.concurrent.TimeoutException . |
<U,Mat2> FlowOps |
concat(Graph<SourceShape<U>,Mat2> that)
|
<U,Mat2> Graph<FlowShape<Out,U>,Mat2> |
concatGraph(Graph<SourceShape<U>,Mat2> that) |
<O2> FlowOps |
conflate(scala.Function2<O2,O2,O2> aggregate)
Allows a faster upstream to progress independently of a slower subscriber by conflating elements into a summary
until the subscriber is ready to accept them.
|
<S> FlowOps |
conflateWithSeed(scala.Function1<Out,S> seed,
scala.Function2<S,Out,S> aggregate)
Allows a faster upstream to progress independently of a slower subscriber by conflating elements into a summary
until the subscriber is ready to accept them.
|
FlowOps |
delay(scala.concurrent.duration.FiniteDuration of,
DelayOverflowStrategy strategy)
Shifts elements emission in time by a specified amount.
|
FlowOps |
detach()
Detaches upstream demand from downstream demand without detaching the
stream rates; in other words acts like a buffer of size 1.
|
FlowOps |
drop(long n)
Discard the given number of elements at the beginning of the stream.
|
FlowOps |
dropWhile(scala.Function1<Out,java.lang.Object> p)
Discard elements at the beginning of the stream while predicate is true.
|
FlowOps |
dropWithin(scala.concurrent.duration.FiniteDuration d)
Discard the elements received within the given duration at beginning of the stream.
|
<U> FlowOps |
expand(scala.Function1<Out,scala.collection.Iterator<U>> extrapolate)
Allows a faster downstream to progress independently of a slower publisher by extrapolating elements from an older
element until new element comes from the upstream.
|
FlowOps |
filter(scala.Function1<Out,java.lang.Object> p)
Only pass on those elements that satisfy the given predicate.
|
FlowOps |
filterNot(scala.Function1<Out,java.lang.Object> p)
Only pass on those elements that NOT satisfy the given predicate.
|
<T,M> FlowOps |
flatMapConcat(scala.Function1<Out,Graph<SourceShape<T>,M>> f)
Transform each input element into a
Source of output elements that is
then flattened into the output stream by concatenation,
fully consuming one Source after the other. |
<T,M> FlowOps |
flatMapMerge(int breadth,
scala.Function1<Out,Graph<SourceShape<T>,M>> f)
Transform each input element into a
Source of output elements that is
then flattened into the output stream by merging, where at most breadth
substreams are being consumed at any given time. |
<T> FlowOps |
fold(T zero,
scala.Function2<T,Out,T> f)
Similar to
scan but only emits its result when the upstream completes,
after which it also completes. |
<T> FlowOps |
foldAsync(T zero,
scala.Function2<T,Out,scala.concurrent.Future<T>> f)
Similar to
fold but with an asynchronous function. |
<K> SubFlow<Out,Mat,FlowOps,java.lang.Object> |
groupBy(int maxSubstreams,
scala.Function1<Out,K> f)
This operation demultiplexes the incoming stream into separate output
streams, one for each element key.
|
FlowOps |
grouped(int n)
Chunk up this stream into groups of the given size, with the last group
possibly smaller than requested due to end-of-stream.
|
FlowOps |
groupedWithin(int n,
scala.concurrent.duration.FiniteDuration d)
Chunk up this stream into groups of elements received within a time window,
or limited by the given number of elements, whatever happens first.
|
FlowOps |
idleTimeout(scala.concurrent.duration.FiniteDuration timeout)
If the time between two processed elements exceeds the provided timeout, the stream is failed
with a
scala.concurrent.TimeoutException . |
FlowOps |
initialDelay(scala.concurrent.duration.FiniteDuration delay)
Delays the initial element by the specified duration.
|
FlowOps |
initialTimeout(scala.concurrent.duration.FiniteDuration timeout)
If the first element has not passed through this stage before the provided timeout, the stream is failed
with a
scala.concurrent.TimeoutException . |
<U> FlowOps |
interleave(Graph<SourceShape<U>,?> that,
int segmentSize)
|
<U,M> Graph<FlowShape<Out,U>,M> |
interleaveGraph(Graph<SourceShape<U>,M> that,
int segmentSize) |
<T> FlowOps |
intersperse(T inject)
Intersperses stream with provided element, similar to how
scala.collection.immutable.List.mkString
injects a separator between a List's elements. |
<T> FlowOps |
intersperse(T start,
T inject,
T end)
Intersperses stream with provided element, similar to how
scala.collection.immutable.List.mkString
injects a separator between a List's elements. |
<U> FlowOps |
keepAlive(scala.concurrent.duration.FiniteDuration maxIdle,
scala.Function0<U> injectedElem)
Injects additional elements if upstream does not emit for a configured amount of time.
|
FlowOps |
limit(long max)
Ensure stream boundedness by limiting the number of elements from upstream.
|
<T> FlowOps |
limitWeighted(long max,
scala.Function1<Out,java.lang.Object> costFn)
Ensure stream boundedness by evaluating the cost of incoming elements
using a cost function.
|
FlowOps |
log(java.lang.String name,
scala.Function1<Out,java.lang.Object> extract,
LoggingAdapter log)
Logs elements flowing through the stream as well as completion and erroring.
|
<T> FlowOps |
map(scala.Function1<Out,T> f)
Transform this stream by applying the given function to each of the elements
as they pass through this processing step.
|
<T> FlowOps |
mapAsync(int parallelism,
scala.Function1<Out,scala.concurrent.Future<T>> f)
Transform this stream by applying the given function to each of the elements
as they pass through this processing step.
|
<T> FlowOps |
mapAsyncUnordered(int parallelism,
scala.Function1<Out,scala.concurrent.Future<T>> f)
Transform this stream by applying the given function to each of the elements
as they pass through this processing step.
|
<T> FlowOps |
mapConcat(scala.Function1<Out,scala.collection.immutable.Iterable<T>> f)
Transform each input element into an
Iterable of output elements that is
then flattened into the output stream. |
FlowOps |
mapError(scala.PartialFunction<java.lang.Throwable,java.lang.Throwable> pf)
While similar to
recover this stage can be used to transform an error signal to a different one *without* logging
it as an error in the process. |
<U,M> FlowOps |
merge(Graph<SourceShape<U>,M> that,
boolean eagerComplete)
|
<U,M> Graph<FlowShape<Out,U>,M> |
mergeGraph(Graph<SourceShape<U>,M> that,
boolean eagerComplete) |
<U,M> FlowOps |
mergeSorted(Graph<SourceShape<U>,M> that,
scala.math.Ordering<U> ord)
|
<U,M> Graph<FlowShape<Out,U>,M> |
mergeSortedGraph(Graph<SourceShape<U>,M> that,
scala.math.Ordering<U> ord) |
FlowOps |
named(java.lang.String name) |
<U,Mat2> FlowOps |
orElse(Graph<SourceShape<U>,Mat2> secondary)
Provides a secondary source that will be consumed if this stream completes without any
elements passing by.
|
<U,Mat2> Graph<FlowShape<Out,U>,Mat2> |
orElseGraph(Graph<SourceShape<U>,Mat2> secondary) |
<U> FlowOps |
prefixAndTail(int n)
Takes up to
n elements from the stream (less than n only if the upstream completes before emitting n elements)
and returns a pair containing a strict sequence of the taken element
and a stream representing the remaining elements. |
<U,Mat2> FlowOps |
prepend(Graph<SourceShape<U>,Mat2> that)
|
<U,Mat2> Graph<FlowShape<Out,U>,Mat2> |
prependGraph(Graph<SourceShape<U>,Mat2> that) |
<T> FlowOps |
recover(scala.PartialFunction<java.lang.Throwable,T> pf)
Recover allows to send last element on failure and gracefully complete the stream
Since the underlying failure signal onError arrives out-of-band, it might jump over existing elements.
|
<T> FlowOps |
recoverWith(scala.PartialFunction<java.lang.Throwable,Graph<SourceShape<T>,NotUsed>> pf)
Deprecated.
Use recoverWithRetries instead. Since 2.4.4.
|
<T> FlowOps |
recoverWithRetries(int attempts,
scala.PartialFunction<java.lang.Throwable,Graph<SourceShape<T>,NotUsed>> pf)
RecoverWithRetries allows to switch to alternative Source on flow failure.
|
<T> FlowOps |
reduce(scala.Function2<T,T,T> f)
Similar to
fold but uses first element as zero element. |
<T> FlowOps |
scan(T zero,
scala.Function2<T,Out,T> f)
Similar to
fold but is not a terminal operation,
emits its current value which starts at zero and then
applies the current and next value to the given function f ,
emitting the next current value. |
<T> FlowOps |
scanAsync(T zero,
scala.Function2<T,Out,scala.concurrent.Future<T>> f)
Similar to
scan but with a asynchronous function,
emits its current value which starts at zero and then
applies the current and next value to the given function f ,
emitting a Future that resolves to the next current value. |
FlowOps |
sliding(int n,
int step)
Apply a sliding window over the stream and return the windows as groups of elements, with the last group
possibly smaller than requested due to end-of-stream.
|
SubFlow<Out,Mat,FlowOps,java.lang.Object> |
splitAfter(scala.Function1<Out,java.lang.Object> p)
This operation applies the given predicate to all incoming elements and
emits them to a stream of output streams.
|
SubFlow<Out,Mat,FlowOps,java.lang.Object> |
splitAfter(SubstreamCancelStrategy substreamCancelStrategy,
scala.Function1<Out,java.lang.Object> p)
This operation applies the given predicate to all incoming elements and
emits them to a stream of output streams.
|
SubFlow<Out,Mat,FlowOps,java.lang.Object> |
splitWhen(scala.Function1<Out,java.lang.Object> p)
This operation applies the given predicate to all incoming elements and
emits them to a stream of output streams, always beginning a new one with
the current element if the given predicate returns true for it.
|
SubFlow<Out,Mat,FlowOps,java.lang.Object> |
splitWhen(SubstreamCancelStrategy substreamCancelStrategy,
scala.Function1<Out,java.lang.Object> p)
This operation applies the given predicate to all incoming elements and
emits them to a stream of output streams, always beginning a new one with
the current element if the given predicate returns true for it.
|
<T> FlowOps |
statefulMapConcat(scala.Function0<scala.Function1<Out,scala.collection.immutable.Iterable<T>>> f)
Transform each input element into an
Iterable of output elements that is
then flattened into the output stream. |
FlowOps |
take(long n)
Terminate processing (and cancel the upstream publisher) after the given
number of elements.
|
FlowOps |
takeWhile(scala.Function1<Out,java.lang.Object> p)
Terminate processing (and cancel the upstream publisher) after predicate
returns false for the first time,
Due to input buffering some elements may have been requested from upstream publishers
that will then not be processed downstream of this step.
|
FlowOps |
takeWhile(scala.Function1<Out,java.lang.Object> p,
boolean inclusive)
Terminate processing (and cancel the upstream publisher) after predicate
returns false for the first time, including the first failed element iff inclusive is true
Due to input buffering some elements may have been requested from upstream publishers
that will then not be processed downstream of this step.
|
FlowOps |
takeWithin(scala.concurrent.duration.FiniteDuration d)
Terminate processing (and cancel the upstream publisher) after the given
duration.
|
FlowOps |
throttle(int cost,
scala.concurrent.duration.FiniteDuration per,
int maximumBurst,
scala.Function1<Out,java.lang.Object> costCalculation,
ThrottleMode mode)
Sends elements downstream with speed limited to
cost/per . |
FlowOps |
throttle(int elements,
scala.concurrent.duration.FiniteDuration per,
int maximumBurst,
ThrottleMode mode)
Sends elements downstream with speed limited to
elements/per . |
<Mat2> java.lang.Object |
to(Graph<SinkShape<Out>,Mat2> sink)
|
<T> FlowOps |
transform(scala.Function0<Stage<Out,T>> mkStage)
Deprecated.
Use via(GraphStage) instead. Since 2.4.3.
|
<T,Mat2> FlowOps |
via(Graph<FlowShape<Out,T>,Mat2> flow) |
FlowOps |
withAttributes(Attributes attr) |
<U> FlowOps |
zip(Graph<SourceShape<U>,?> that)
Combine the elements of current flow and the given
Source into a stream of tuples. |
<U,M> Graph<FlowShape<Out,scala.Tuple2<Out,U>>,M> |
zipGraph(Graph<SourceShape<U>,M> that) |
<Out2,Out3> |
zipWith(Graph<SourceShape<Out2>,?> that,
scala.Function2<Out,Out2,Out3> combine)
Put together the elements of current flow and the given
Source
into a stream of combined elements using a combiner function. |
<Out2,Out3,M> |
zipWithGraph(Graph<SourceShape<Out2>,M> that,
scala.Function2<Out,Out2,Out3> combine) |
FlowOps |
zipWithIndex()
Combine the elements of current flow into a stream of tuples consisting
of all elements paired with their index.
|
<T> FlowOps recover(scala.PartialFunction<java.lang.Throwable,T> pf)
Throwing an exception inside recover
_will_ be logged on ERROR level automatically.
'''Emits when''' element is available from the upstream or upstream is failed and pf returns an element
'''Backpressures when''' downstream backpressures
'''Completes when''' upstream completes or upstream failed with exception pf can handle
'''Cancels when''' downstream cancels
pf
- (undocumented)<T> FlowOps recoverWith(scala.PartialFunction<java.lang.Throwable,Graph<SourceShape<T>,NotUsed>> pf)
pf
and a new
Source may be materialized.
Since the underlying failure signal onError arrives out-of-band, it might jump over existing elements. This stage can recover the failure signal, but not the skipped elements, which will be dropped.
Throwing an exception inside recoverWith
_will_ be logged on ERROR level automatically.
'''Emits when''' element is available from the upstream or upstream is failed and element is available from alternative Source
'''Backpressures when''' downstream backpressures
'''Completes when''' upstream completes or upstream failed with exception pf can handle
'''Cancels when''' downstream cancels
pf
- (undocumented)<T> FlowOps recoverWithRetries(int attempts, scala.PartialFunction<java.lang.Throwable,Graph<SourceShape<T>,NotUsed>> pf)
attempts
number of times so that each time there is a failure
it is fed into the pf
and a new Source may be materialized. Note that if you pass in 0, this won't
attempt to recover at all. Passing -1 will behave exactly the same as recoverWith
.
Since the underlying failure signal onError arrives out-of-band, it might jump over existing elements. This stage can recover the failure signal, but not the skipped elements, which will be dropped.
Throwing an exception inside recoverWithRetries
_will_ be logged on ERROR level automatically.
'''Emits when''' element is available from the upstream or upstream is failed and element is available from alternative Source
'''Backpressures when''' downstream backpressures
'''Completes when''' upstream completes or upstream failed with exception pf can handle
'''Cancels when''' downstream cancels
attempts
- Maximum number of retries or -1 to retry indefinitelypf
- Receives the failure cause and returns the new Source to be materialized if anyjava.lang.IllegalArgumentException
- if attempts
is a negative number other than -1
FlowOps mapError(scala.PartialFunction<java.lang.Throwable,java.lang.Throwable> pf)
recover
this stage can be used to transform an error signal to a different one *without* logging
it as an error in the process. So in that sense it is NOT exactly equivalent to recover(t => throw t2)
since recover
would log the t2
error.
Since the underlying failure signal onError arrives out-of-band, it might jump over existing elements. This stage can recover the failure signal, but not the skipped elements, which will be dropped.
Similarily to recover
throwing an exception inside mapError
_will_ be logged.
'''Emits when''' element is available from the upstream or upstream is failed and pf returns an element
'''Backpressures when''' downstream backpressures
'''Completes when''' upstream completes or upstream failed with exception pf can handle
'''Cancels when''' downstream cancels
pf
- (undocumented)<T> FlowOps map(scala.Function1<Out,T> f)
'''Emits when''' the mapping function returns an element
'''Backpressures when''' downstream backpressures
'''Completes when''' upstream completes
'''Cancels when''' downstream cancels
f
- (undocumented)<T> FlowOps mapConcat(scala.Function1<Out,scala.collection.immutable.Iterable<T>> f)
Iterable
of output elements that is
then flattened into the output stream.
The returned Iterable
MUST NOT contain null
values,
as they are illegal as stream elements - according to the Reactive Streams specification.
'''Emits when''' the mapping function returns an element or there are still remaining elements from the previously calculated collection
'''Backpressures when''' downstream backpressures or there are still remaining elements from the previously calculated collection
'''Completes when''' upstream completes and all remaining elements have been emitted
'''Cancels when''' downstream cancels
f
- (undocumented)<T> FlowOps statefulMapConcat(scala.Function0<scala.Function1<Out,scala.collection.immutable.Iterable<T>>> f)
Iterable
of output elements that is
then flattened into the output stream. The transformation is meant to be stateful,
which is enabled by creating the transformation function anew for every materialization —
the returned function will typically close over mutable objects to store state between
invocations. For the stateless variant see FlowOps.mapConcat
.
The returned Iterable
MUST NOT contain null
values,
as they are illegal as stream elements - according to the Reactive Streams specification.
'''Emits when''' the mapping function returns an element or there are still remaining elements from the previously calculated collection
'''Backpressures when''' downstream backpressures or there are still remaining elements from the previously calculated collection
'''Completes when''' upstream completes and all remaining elements has been emitted
'''Cancels when''' downstream cancels
See also FlowOps.mapConcat
f
- (undocumented)<T> FlowOps mapAsync(int parallelism, scala.Function1<Out,scala.concurrent.Future<T>> f)
Future
and the
value of that future will be emitted downstream. The number of Futures
that shall run in parallel is given as the first argument to
mapAsync
.
These Futures may complete in any order, but the elements that
are emitted downstream are in the same order as received from upstream.
If the function f
throws an exception or if the Future
is completed
with failure and the supervision decision is akka.stream.Supervision.Stop
the stream will be completed with failure.
If the function f
throws an exception or if the Future
is completed
with failure and the supervision decision is akka.stream.Supervision.Resume
or
akka.stream.Supervision.Restart
the element is dropped and the stream continues.
The function f
is always invoked on the elements in the order they arrive.
'''Emits when''' the Future returned by the provided function finishes for the next element in sequence
'''Backpressures when''' the number of futures reaches the configured parallelism and the downstream backpressures or the first future is not completed
'''Completes when''' upstream completes and all futures have been completed and all elements have been emitted
'''Cancels when''' downstream cancels
parallelism
- (undocumented)f
- (undocumented)mapAsyncUnordered(int, scala.Function1<Out, scala.concurrent.Future<T>>)
<T> FlowOps mapAsyncUnordered(int parallelism, scala.Function1<Out,scala.concurrent.Future<T>> f)
Future
and the
value of that future will be emitted downstream. The number of Futures
that shall run in parallel is given as the first argument to
mapAsyncUnordered
.
Each processed element will be emitted downstream as soon as it is ready, i.e. it is possible
that the elements are not emitted downstream in the same order as received from upstream.
If the function f
throws an exception or if the Future
is completed
with failure and the supervision decision is akka.stream.Supervision.Stop
the stream will be completed with failure.
If the function f
throws an exception or if the Future
is completed
with failure and the supervision decision is akka.stream.Supervision.Resume
or
akka.stream.Supervision.Restart
the element is dropped and the stream continues.
The function f
is always invoked on the elements in the order they arrive (even though the result of the futures
returned by f
might be emitted in a different order).
'''Emits when''' any of the Futures returned by the provided function complete
'''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
'''Cancels when''' downstream cancels
parallelism
- (undocumented)f
- (undocumented)mapAsync(int, scala.Function1<Out, scala.concurrent.Future<T>>)
FlowOps filter(scala.Function1<Out,java.lang.Object> p)
'''Emits when''' the given predicate returns true for the element
'''Backpressures when''' the given predicate returns true for the element and downstream backpressures
'''Completes when''' upstream completes
'''Cancels when''' downstream cancels
p
- (undocumented)FlowOps filterNot(scala.Function1<Out,java.lang.Object> p)
'''Emits when''' the given predicate returns false for the element
'''Backpressures when''' the given predicate returns false for the element and downstream backpressures
'''Completes when''' upstream completes
'''Cancels when''' downstream cancels
p
- (undocumented)FlowOps takeWhile(scala.Function1<Out,java.lang.Object> p)
The stream will be completed without producing any elements if predicate is false for the first stream element.
'''Emits when''' the predicate is true
'''Backpressures when''' downstream backpressures
'''Completes when''' predicate returned false (or 1 after predicate returns false if inclusive
or upstream completes
'''Cancels when''' predicate returned false or downstream cancels
See also FlowOps.limit
, FlowOps.limitWeighted
p
- (undocumented)FlowOps takeWhile(scala.Function1<Out,java.lang.Object> p, boolean inclusive)
The stream will be completed without producing any elements if predicate is false for the first stream element.
'''Emits when''' the predicate is true
'''Backpressures when''' downstream backpressures
'''Completes when''' predicate returned false (or 1 after predicate returns false if inclusive
or upstream completes
'''Cancels when''' predicate returned false or downstream cancels
See also FlowOps.limit
, FlowOps.limitWeighted
p
- (undocumented)inclusive
- (undocumented)FlowOps dropWhile(scala.Function1<Out,java.lang.Object> p)
'''Emits when''' predicate returned false and for all following stream elements
'''Backpressures when''' predicate returned false and downstream backpressures
'''Completes when''' upstream completes
'''Cancels when''' downstream cancels
p
- (undocumented)<T> FlowOps collect(scala.PartialFunction<Out,T> pf)
'''Emits when''' the provided partial function is defined for the element
'''Backpressures when''' the partial function is defined for the element and downstream backpressures
'''Completes when''' upstream completes
'''Cancels when''' downstream cancels
pf
- (undocumented)FlowOps grouped(int n)
n
must be positive, otherwise IllegalArgumentException is thrown.
'''Emits when''' the specified number of elements have been accumulated or upstream completed
'''Backpressures when''' a group has been assembled and downstream backpressures
'''Completes when''' upstream completes
'''Cancels when''' downstream cancels
n
- (undocumented)FlowOps limit(long max)
StreamLimitException
downstream.
Due to input buffering some elements may have been requested from upstream publishers that will then not be processed downstream of this step.
'''Emits when''' upstream emits and the number of emitted elements has not reached max
'''Backpressures when''' downstream backpressures
'''Completes when''' upstream completes and the number of emitted elements has not reached max
'''Errors when''' the total number of incoming element exceeds max
'''Cancels when''' downstream cancels
See also FlowOps.take
, FlowOps.takeWithin
, FlowOps.takeWhile
max
- (undocumented)<T> FlowOps limitWeighted(long max, scala.Function1<Out,java.lang.Object> costFn)
StreamLimitException
downstream.
Due to input buffering some elements may have been requested from upstream publishers that will then not be processed downstream of this step.
'''Emits when''' upstream emits and the accumulated cost has not reached max
'''Backpressures when''' downstream backpressures
'''Completes when''' upstream completes and the number of emitted elements has not reached max
'''Errors when''' when the accumulated cost exceeds max
'''Cancels when''' downstream cancels
See also FlowOps.take
, FlowOps.takeWithin
, FlowOps.takeWhile
max
- (undocumented)costFn
- (undocumented)FlowOps sliding(int n, int step)
n
must be positive, otherwise IllegalArgumentException is thrown.
step
must be positive, otherwise IllegalArgumentException is thrown.
'''Emits when''' enough elements have been collected within the window or upstream completed
'''Backpressures when''' a window has been assembled and downstream backpressures
'''Completes when''' upstream completes
'''Cancels when''' downstream cancels
n
- (undocumented)step
- (undocumented)<T> FlowOps scan(T zero, scala.Function2<T,Out,T> f)
fold
but is not a terminal operation,
emits its current value which starts at zero
and then
applies the current and next value to the given function f
,
emitting the next current value.
If the function f
throws an exception and the supervision decision is
akka.stream.Supervision.Restart
current value starts at zero
again
the stream will continue.
'''Emits when''' the function scanning the element returns a new element
'''Backpressures when''' downstream backpressures
'''Completes when''' upstream completes
'''Cancels when''' downstream cancels
See also FlowOps.scanAsync
zero
- (undocumented)f
- (undocumented)<T> FlowOps scanAsync(T zero, scala.Function2<T,Out,scala.concurrent.Future<T>> f)
scan
but with a asynchronous function,
emits its current value which starts at zero
and then
applies the current and next value to the given function f
,
emitting a Future
that resolves to the next current value.
If the function f
throws an exception and the supervision decision is
akka.stream.Supervision.Restart
current value starts at zero
again
the stream will continue.
If the function f
throws an exception and the supervision decision is
akka.stream.Supervision.Resume
current value starts at the previous
current value, or zero when it doesn't have one, and the stream will continue.
'''Emits when''' the future returned by f completes
'''Backpressures when''' downstream backpressures
'''Completes when''' upstream completes and the last future returned by f
completes
'''Cancels when''' downstream cancels
See also FlowOps.scan
zero
- (undocumented)f
- (undocumented)<T> FlowOps fold(T zero, scala.Function2<T,Out,T> f)
scan
but only emits its result when the upstream completes,
after which it also completes. Applies the given function towards its current and next value,
yielding the next current value.
If the function f
throws an exception and the supervision decision is
akka.stream.Supervision.Restart
current value starts at zero
again
the stream will continue.
'''Emits when''' upstream completes
'''Backpressures when''' downstream backpressures
'''Completes when''' upstream completes
'''Cancels when''' downstream cancels
See also FlowOps.scan
zero
- (undocumented)f
- (undocumented)<T> FlowOps foldAsync(T zero, scala.Function2<T,Out,scala.concurrent.Future<T>> f)
fold
but with an asynchronous function.
Applies the given function towards its current and next value,
yielding the next current value.
If the function f
returns a failure and the supervision decision is
akka.stream.Supervision.Restart
current value starts at zero
again
the stream will continue.
'''Emits when''' upstream completes
'''Backpressures when''' downstream backpressures
'''Completes when''' upstream completes
'''Cancels when''' downstream cancels
See also FlowOps.fold
zero
- (undocumented)f
- (undocumented)<T> FlowOps reduce(scala.Function2<T,T,T> f)
fold
but uses first element as zero element.
Applies the given function towards its current and next value,
yielding the next current value.
If the stream is empty (i.e. completes before signalling any elements),
the reduce stage will fail its downstream with a NoSuchElementException
,
which is semantically in-line with that Scala's standard library collections
do in such situations.
'''Emits when''' upstream completes
'''Backpressures when''' downstream backpressures
'''Completes when''' upstream completes
'''Cancels when''' downstream cancels
See also FlowOps.fold
f
- (undocumented)<T> FlowOps intersperse(T start, T inject, T end)
scala.collection.immutable.List.mkString
injects a separator between a List's elements.
Additionally can inject start and end marker elements to stream.
Examples:
val nums = Source(List(1,2,3)).map(_.toString)
nums.intersperse(",") // 1 , 2 , 3
nums.intersperse("[", ",", "]") // [ 1 , 2 , 3 ]
In case you want to only prepend or only append an element (yet still use the intercept
feature
to inject a separator between elements, you may want to use the following pattern instead of the 3-argument
version of intersperse (See Source.concat
for semantics details):
Source.single(">> ") ++ Source(List("1", "2", "3")).intersperse(",")
Source(List("1", "2", "3")).intersperse(",") ++ Source.single("END")
'''Emits when''' upstream emits (or before with the start
element if provided)
'''Backpressures when''' downstream backpressures
'''Completes when''' upstream completes
'''Cancels when''' downstream cancels
start
- (undocumented)inject
- (undocumented)end
- (undocumented)<T> FlowOps intersperse(T inject)
scala.collection.immutable.List.mkString
injects a separator between a List's elements.
Additionally can inject start and end marker elements to stream.
Examples:
val nums = Source(List(1,2,3)).map(_.toString)
nums.intersperse(",") // 1 , 2 , 3
nums.intersperse("[", ",", "]") // [ 1 , 2 , 3 ]
'''Emits when''' upstream emits (or before with the start
element if provided)
'''Backpressures when''' downstream backpressures
'''Completes when''' upstream completes
'''Cancels when''' downstream cancels
inject
- (undocumented)FlowOps groupedWithin(int n, scala.concurrent.duration.FiniteDuration d)
n
must be positive, and d
must be greater than 0 seconds, otherwise
IllegalArgumentException is thrown.
'''Emits when''' the configured time elapses since the last group has been emitted
'''Backpressures when''' the configured time elapses since the last group has been emitted
'''Completes when''' upstream completes (emits last group)
'''Cancels when''' downstream completes
n
- (undocumented)d
- (undocumented)FlowOps delay(scala.concurrent.duration.FiniteDuration of, DelayOverflowStrategy strategy)
DelayOverflowStrategy
it might drop elements or backpressure the upstream if
there is no space available in the buffer.
Delay precision is 10ms to avoid unnecessary timer scheduling cycles
Internal buffer has default capacity 16. You can set buffer size by calling withAttributes(inputBuffer)
'''Emits when''' there is a pending element in the buffer and configured time for this element elapsed * EmitEarly - strategy do not wait to emit element if buffer is full
'''Backpressures when''' depending on OverflowStrategy * Backpressure - backpressures when buffer is full * DropHead, DropTail, DropBuffer - never backpressures * Fail - fails the stream if buffer gets full
'''Completes when''' upstream completes and buffered elements have been drained
'''Cancels when''' downstream cancels
of
- time to shift all messagesstrategy
- Strategy that is used when incoming elements cannot fit inside the bufferFlowOps drop(long n)
n
is zero or negative.
'''Emits when''' the specified number of elements has been dropped already
'''Backpressures when''' the specified number of elements has been dropped and downstream backpressures
'''Completes when''' upstream completes
'''Cancels when''' downstream cancels
n
- (undocumented)FlowOps dropWithin(scala.concurrent.duration.FiniteDuration d)
'''Emits when''' the specified time elapsed and a new upstream element arrives
'''Backpressures when''' downstream backpressures
'''Completes when''' upstream completes
'''Cancels when''' downstream cancels
d
- (undocumented)FlowOps take(long n)
The stream will be completed without producing any elements if n
is zero
or negative.
'''Emits when''' the specified number of elements to take has not yet been reached
'''Backpressures when''' downstream backpressures
'''Completes when''' the defined number of elements has been taken or upstream completes
'''Cancels when''' the defined number of elements has been taken or downstream cancels
See also FlowOps.limit
, FlowOps.limitWeighted
n
- (undocumented)FlowOps takeWithin(scala.concurrent.duration.FiniteDuration d)
Note that this can be combined with take(long)
to limit the number of elements
within the duration.
'''Emits when''' an upstream element arrives
'''Backpressures when''' downstream backpressures
'''Completes when''' upstream completes or timer fires
'''Cancels when''' downstream cancels or timer fires
d
- (undocumented)<S> FlowOps conflateWithSeed(scala.Function1<Out,S> seed, scala.Function2<S,Out,S> aggregate)
This version of conflate allows to derive a seed from the first element and change the aggregated type to be
different than the input type. See FlowOps.conflate
for a simpler version that does not change types.
This element only rolls up elements if the upstream is faster, but if the downstream is faster it will not duplicate elements.
'''Emits when''' downstream stops backpressuring and there is a conflated element available
'''Backpressures when''' never
'''Completes when''' upstream completes
'''Cancels when''' downstream cancels
seed
- Provides the first state for a conflated value using the first unconsumed element as a startaggregate
- Takes the currently aggregated value and the current pending element to produce a new aggregate
See also FlowOps.conflate
, FlowOps.limit
, FlowOps.limitWeighted
FlowOps.batch
FlowOps.batchWeighted
<O2> FlowOps conflate(scala.Function2<O2,O2,O2> aggregate)
This version of conflate does not change the output type of the stream. See FlowOps.conflateWithSeed
for a
more flexible version that can take a seed function and transform elements while rolling up.
This element only rolls up elements if the upstream is faster, but if the downstream is faster it will not duplicate elements.
'''Emits when''' downstream stops backpressuring and there is a conflated element available
'''Backpressures when''' never
'''Completes when''' upstream completes
'''Cancels when''' downstream cancels
aggregate
- Takes the currently aggregated value and the current pending element to produce a new aggregate
See also FlowOps.conflate
, FlowOps.limit
, FlowOps.limitWeighted
FlowOps.batch
FlowOps.batchWeighted
<S> FlowOps batch(long max, scala.Function1<Out,S> seed, scala.Function2<S,Out,S> aggregate)
This only rolls up elements if the upstream is faster, but if the downstream is faster it will not duplicate elements.
'''Emits when''' downstream stops backpressuring and there is an aggregated element available
'''Backpressures when''' there are max
batched elements and 1 pending element and downstream backpressures
'''Completes when''' upstream completes and there is no batched/pending element waiting
'''Cancels when''' downstream cancels
See also FlowOps.conflateWithSeed
, FlowOps.batchWeighted
max
- maximum number of elements to batch before backpressuring upstream (must be positive non-zero)seed
- Provides the first state for a batched value using the first unconsumed element as a startaggregate
- Takes the currently batched value and the current pending element to produce a new aggregate<S> FlowOps batchWeighted(long max, scala.Function1<Out,java.lang.Object> costFn, scala.Function1<Out,S> seed, scala.Function2<S,Out,S> aggregate)
ByteString
elements up to the allowed max limit if the upstream publisher is faster.
This element only rolls up elements if the upstream is faster, but if the downstream is faster it will not duplicate elements.
Batching will apply for all elements, even if a single element cost is greater than the total allowed limit.
In this case, previous batched elements will be emitted, then the "heavy" element will be emitted (after
being applied with the seed
function) without batching further elements with it, and then the rest of the
incoming elements are batched.
'''Emits when''' downstream stops backpressuring and there is a batched element available
'''Backpressures when''' there are max
weighted batched elements + 1 pending element and downstream backpressures
'''Completes when''' upstream completes and there is no batched/pending element waiting
'''Cancels when''' downstream cancels
See also FlowOps.conflateWithSeed
, FlowOps.batch
max
- maximum weight of elements to batch before backpressuring upstream (must be positive non-zero)costFn
- a function to compute a single element weightseed
- Provides the first state for a batched value using the first unconsumed element as a startaggregate
- Takes the currently batched value and the current pending element to produce a new batch<U> FlowOps expand(scala.Function1<Out,scala.collection.Iterator<U>> extrapolate)
This element will never "drop" upstream elements as all elements go through at least one extrapolation step. This means that if the upstream is actually faster than the upstream it will be backpressured by the downstream subscriber.
Expand does not support akka.stream.Supervision.Restart
and akka.stream.Supervision.Resume
.
Exceptions from the seed
or extrapolate
functions will complete the stream with failure.
'''Emits when''' downstream stops backpressuring
'''Backpressures when''' downstream backpressures or iterator runs empty
'''Completes when''' upstream completes
'''Cancels when''' downstream cancels
seed
- Provides the first state for extrapolation using the first unconsumed elementextrapolate
- Takes the current extrapolation state to produce an output element and the next extrapolation
state.FlowOps buffer(int size, OverflowStrategy overflowStrategy)
OverflowStrategy
it might drop elements or backpressure the upstream if
there is no space available
'''Emits when''' downstream stops backpressuring and there is a pending element in the buffer
'''Backpressures when''' depending on OverflowStrategy * Backpressure - backpressures when buffer is full * DropHead, DropTail, DropBuffer - never backpressures * Fail - fails the stream if buffer gets full
'''Completes when''' upstream completes and buffered elements have been drained
'''Cancels when''' downstream cancels
size
- The size of the buffer in element countoverflowStrategy
- Strategy that is used when incoming elements cannot fit inside the buffer<T> FlowOps transform(scala.Function0<Stage<Out,T>> mkStage)
Stage
.
This operator makes it possible to extend the Flow
API when there is no specialized
operator that performs the transformation.mkStage
- (undocumented)<U> FlowOps prefixAndTail(int n)
n
elements from the stream (less than n
only if the upstream completes before emitting n
elements)
and returns a pair containing a strict sequence of the taken element
and a stream representing the remaining elements. If ''n'' is zero or negative, then this will return a pair
of an empty collection and a stream containing the whole upstream unchanged.
In case of an upstream error, depending on the current state
- the master stream signals the error if less than n
elements has been seen, and therefore the substream
has not yet been emitted
- the tail substream signals the error after the prefix and tail has been emitted by the main stream
(at that point the main stream has already completed)
'''Emits when''' the configured number of prefix elements are available. Emits this prefix, and the rest as a substream
'''Backpressures when''' downstream backpressures or substream backpressures
'''Completes when''' prefix elements have been consumed and substream has been consumed
'''Cancels when''' downstream cancels or substream cancels
n
- (undocumented)<K> SubFlow<Out,Mat,FlowOps,java.lang.Object> groupBy(int maxSubstreams, scala.Function1<Out,K> f)
The object returned from this method is not a normal Source
or Flow
,
it is a SubFlow
. This means that after this combinator all transformations
are applied to all encountered substreams in the same fashion. Substream mode
is exited either by closing the substream (i.e. connecting it to a Sink
)
or by merging the substreams back together; see the to
and mergeBack
methods
on SubFlow
for more information.
It is important to note that the substreams also propagate back-pressure as
any other stream, which means that blocking one substream will block the groupBy
operator itself—and thereby all substreams—once all internal or
explicit buffers are filled.
If the group by function f
throws an exception and the supervision decision
is akka.stream.Supervision.Stop
the stream and substreams will be completed
with failure.
If the group by function f
throws an exception and the supervision decision
is akka.stream.Supervision.Resume
or akka.stream.Supervision.Restart
the element is dropped and the stream and substreams continue.
Function f
MUST NOT return null
. This will throw exception and trigger supervision decision mechanism.
'''Emits when''' an element for which the grouping function returns a group that has not yet been created. Emits the new group
'''Backpressures when''' there is an element pending for a group whose substream backpressures
'''Completes when''' upstream completes
'''Cancels when''' downstream cancels and all substreams cancel
maxSubstreams
- configures the maximum number of substreams (keys)
that are supported; if more distinct keys are encountered then the stream failsf
- (undocumented)SubFlow<Out,Mat,FlowOps,java.lang.Object> splitWhen(SubstreamCancelStrategy substreamCancelStrategy, scala.Function1<Out,java.lang.Object> p)
false, // element goes into first substream
true, false, // elements go into second substream
true, false, false // elements go into third substream
In case the *first* element of the stream matches the predicate, the first substream emitted by splitWhen will start from that element. For example:
true, false, false // first substream starts from the split-by element
true, false // subsequent substreams operate the same way
The object returned from this method is not a normal Source
or Flow
,
it is a SubFlow
. This means that after this combinator all transformations
are applied to all encountered substreams in the same fashion. Substream mode
is exited either by closing the substream (i.e. connecting it to a Sink
)
or by merging the substreams back together; see the to
and mergeBack
methods
on SubFlow
for more information.
It is important to note that the substreams also propagate back-pressure as
any other stream, which means that blocking one substream will block the splitWhen
operator itself—and thereby all substreams—once all internal or
explicit buffers are filled.
If the split predicate p
throws an exception and the supervision decision
is akka.stream.Supervision.Stop
the stream and substreams will be completed
with failure.
If the split predicate p
throws an exception and the supervision decision
is akka.stream.Supervision.Resume
or akka.stream.Supervision.Restart
the element is dropped and the stream and substreams continue.
'''Emits when''' an element for which the provided predicate is true, opening and emitting a new substream for subsequent element
'''Backpressures when''' there is an element pending for the next substream, but the previous is not fully consumed yet, or the substream backpressures
'''Completes when''' upstream completes
'''Cancels when''' downstream cancels and substreams cancel on SubstreamCancelStrategy.drain
, downstream
cancels or any substream cancels on SubstreamCancelStrategy.propagate
See also FlowOps.splitAfter
.
substreamCancelStrategy
- (undocumented)p
- (undocumented)SubFlow<Out,Mat,FlowOps,java.lang.Object> splitWhen(scala.Function1<Out,java.lang.Object> p)
p
- (undocumented)splitWhen(akka.stream.SubstreamCancelStrategy, scala.Function1<Out, java.lang.Object>)
SubFlow<Out,Mat,FlowOps,java.lang.Object> splitAfter(SubstreamCancelStrategy substreamCancelStrategy, scala.Function1<Out,java.lang.Object> p)
false, true, // elements go into first substream
false, true, // elements go into second substream
false, false, true // elements go into third substream
The object returned from this method is not a normal Source
or Flow
,
it is a SubFlow
. This means that after this combinator all transformations
are applied to all encountered substreams in the same fashion. Substream mode
is exited either by closing the substream (i.e. connecting it to a Sink
)
or by merging the substreams back together; see the to
and mergeBack
methods
on SubFlow
for more information.
It is important to note that the substreams also propagate back-pressure as
any other stream, which means that blocking one substream will block the splitAfter
operator itself—and thereby all substreams—once all internal or
explicit buffers are filled.
If the split predicate p
throws an exception and the supervision decision
is akka.stream.Supervision.Stop
the stream and substreams will be completed
with failure.
If the split predicate p
throws an exception and the supervision decision
is akka.stream.Supervision.Resume
or akka.stream.Supervision.Restart
the element is dropped and the stream and substreams continue.
'''Emits when''' an element passes through. When the provided predicate is true it emits the element and opens a new substream for subsequent element
'''Backpressures when''' there is an element pending for the next substream, but the previous is not fully consumed yet, or the substream backpressures
'''Completes when''' upstream completes
'''Cancels when''' downstream cancels and substreams cancel on SubstreamCancelStrategy.drain
, downstream
cancels or any substream cancels on SubstreamCancelStrategy.propagate
See also FlowOps.splitWhen
.
substreamCancelStrategy
- (undocumented)p
- (undocumented)SubFlow<Out,Mat,FlowOps,java.lang.Object> splitAfter(scala.Function1<Out,java.lang.Object> p)
p
- (undocumented)splitAfter(akka.stream.SubstreamCancelStrategy, scala.Function1<Out, java.lang.Object>)
<T,M> FlowOps flatMapConcat(scala.Function1<Out,Graph<SourceShape<T>,M>> f)
Source
of output elements that is
then flattened into the output stream by concatenation,
fully consuming one Source after the other.
'''Emits when''' a currently consumed substream has an element available
'''Backpressures when''' downstream backpressures
'''Completes when''' upstream completes and all consumed substreams complete
'''Cancels when''' downstream cancels
f
- (undocumented)<T,M> FlowOps flatMapMerge(int breadth, scala.Function1<Out,Graph<SourceShape<T>,M>> f)
Source
of output elements that is
then flattened into the output stream by merging, where at most breadth
substreams are being consumed at any given time.
'''Emits when''' a currently consumed substream has an element available
'''Backpressures when''' downstream backpressures
'''Completes when''' upstream completes and all consumed substreams complete
'''Cancels when''' downstream cancels
breadth
- (undocumented)f
- (undocumented)FlowOps initialTimeout(scala.concurrent.duration.FiniteDuration timeout)
scala.concurrent.TimeoutException
.
'''Emits when''' upstream emits an element
'''Backpressures when''' downstream backpressures
'''Completes when''' upstream completes or fails if timeout elapses before first element arrives
'''Cancels when''' downstream cancels
timeout
- (undocumented)FlowOps completionTimeout(scala.concurrent.duration.FiniteDuration timeout)
scala.concurrent.TimeoutException
.
'''Emits when''' upstream emits an element
'''Backpressures when''' downstream backpressures
'''Completes when''' upstream completes or fails if timeout elapses before upstream completes
'''Cancels when''' downstream cancels
timeout
- (undocumented)FlowOps idleTimeout(scala.concurrent.duration.FiniteDuration timeout)
scala.concurrent.TimeoutException
. The timeout is checked periodically,
so the resolution of the check is one period (equals to timeout value).
'''Emits when''' upstream emits an element
'''Backpressures when''' downstream backpressures
'''Completes when''' upstream completes or fails if timeout elapses between two emitted elements
'''Cancels when''' downstream cancels
timeout
- (undocumented)FlowOps backpressureTimeout(scala.concurrent.duration.FiniteDuration timeout)
scala.concurrent.TimeoutException
. The timeout is checked periodically,
so the resolution of the check is one period (equals to timeout value).
'''Emits when''' upstream emits an element
'''Backpressures when''' downstream backpressures
'''Completes when''' upstream completes or fails if timeout elapses between element emission and downstream demand.
'''Cancels when''' downstream cancels
timeout
- (undocumented)<U> FlowOps keepAlive(scala.concurrent.duration.FiniteDuration maxIdle, scala.Function0<U> injectedElem)
If the downstream backpressures then no element is injected until downstream demand arrives. Injected elements do not accumulate during this period.
Upstream elements are always preferred over injected elements.
'''Emits when''' upstream emits an element or if the upstream was idle for the configured period
'''Backpressures when''' downstream backpressures
'''Completes when''' upstream completes
'''Cancels when''' downstream cancels
maxIdle
- (undocumented)injectedElem
- (undocumented)FlowOps throttle(int elements, scala.concurrent.duration.FiniteDuration per, int maximumBurst, ThrottleMode mode)
elements/per
. In other words, this stage set the maximum rate
for emitting messages. This combinator works for streams where all elements have the same cost or length.
Throttle implements the token bucket model. There is a bucket with a given token capacity (burst size or maximumBurst).
Tokens drops into the bucket at a given rate and can be spared
for later use up to bucket capacity
to allow some burstiness. Whenever stream wants to send an element, it takes as many
tokens from the bucket as number of elements. If there isn't any, throttle waits until the
bucket accumulates enough tokens. Bucket is full when stream just materialized and started.
Parameter mode
manages behaviour when upstream is faster than throttle rate:
- akka.stream.ThrottleMode.Shaping
makes pauses before emitting messages to meet throttle rate
- akka.stream.ThrottleMode.Enforcing
fails with exception when upstream is faster than throttle rate. Enforcing
cannot emit elements that cost more than the maximumBurst
'''Emits when''' upstream emits an element and configured time per each element elapsed
'''Backpressures when''' downstream backpressures
'''Completes when''' upstream completes
'''Cancels when''' downstream cancels
elements
- (undocumented)per
- (undocumented)maximumBurst
- (undocumented)mode
- (undocumented)FlowOps throttle(int cost, scala.concurrent.duration.FiniteDuration per, int maximumBurst, scala.Function1<Out,java.lang.Object> costCalculation, ThrottleMode mode)
cost/per
. Cost is
calculating for each element individually by calling calculateCost
function.
This combinator works for streams when elements have different cost(length).
Streams of ByteString
for example.
Throttle implements the token bucket model. There is a bucket with a given token capacity (burst size or maximumBurst).
Tokens drops into the bucket at a given rate and can be spared
for later use up to bucket capacity
to allow some burstiness. Whenever stream wants to send an element, it takes as many
tokens from the bucket as element cost. If there isn't any, throttle waits until the
bucket accumulates enough tokens. Elements that costs more than the allowed burst will be delayed proportionally
to their cost minus available tokens, meeting the target rate.
It is recommended to use non-zero burst sizes as they improve both performance and throttling precision by allowing the implementation to avoid using the scheduler when input rates fall below the enforced limit and to reduce most of the inaccuracy caused by the scheduler resolution (which is in the range of milliseconds).
Throttler always enforces the rate limit, but in certain cases (mostly due to limited scheduler resolution) it enforces a tighter bound than what was prescribed. This can be also mitigated by increasing the burst size.
Parameter mode
manages behaviour when upstream is faster than throttle rate:
- akka.stream.ThrottleMode.Shaping
makes pauses before emitting messages to meet throttle rate
- akka.stream.ThrottleMode.Enforcing
fails with exception when upstream is faster than throttle rate. Enforcing
cannot emit elements that cost more than the maximumBurst
'''Emits when''' upstream emits an element and configured time per each element elapsed
'''Backpressures when''' downstream backpressures
'''Completes when''' upstream completes
'''Cancels when''' downstream cancels
cost
- (undocumented)per
- (undocumented)maximumBurst
- (undocumented)costCalculation
- (undocumented)mode
- (undocumented)FlowOps detach()
'''Emits when''' upstream emits an element
'''Backpressures when''' downstream backpressures
'''Completes when''' upstream completes
'''Cancels when''' downstream cancels
FlowOps initialDelay(scala.concurrent.duration.FiniteDuration delay)
'''Emits when''' upstream emits an element if the initial delay is already elapsed
'''Backpressures when''' downstream backpressures or initial delay is not yet elapsed
'''Completes when''' upstream completes
'''Cancels when''' downstream cancels
delay
- (undocumented)FlowOps log(java.lang.String name, scala.Function1<Out,java.lang.Object> extract, LoggingAdapter log)
By default element and completion signals are logged on debug level, and errors are logged on Error level.
This can be adjusted according to your needs by providing a custom Attributes.LogLevels
attribute on the given Flow:
Uses implicit LoggingAdapter
if available, otherwise uses an internally created one,
which uses akka.stream.Log
as it's source (use this class to configure slf4j loggers).
'''Emits when''' the mapping function returns an element
'''Backpressures when''' downstream backpressures
'''Completes when''' upstream completes
'''Cancels when''' downstream cancels
name
- (undocumented)extract
- (undocumented)log
- (undocumented)<U> FlowOps zip(Graph<SourceShape<U>,?> that)
Source
into a stream of tuples.
'''Emits when''' all of the inputs have an element available
'''Backpressures when''' downstream backpressures
'''Completes when''' any upstream completes
'''Cancels when''' downstream cancels
that
- (undocumented)<Out2,Out3> FlowOps zipWith(Graph<SourceShape<Out2>,?> that, scala.Function2<Out,Out2,Out3> combine)
Source
into a stream of combined elements using a combiner function.
'''Emits when''' all of the inputs have an element available
'''Backpressures when''' downstream backpressures
'''Completes when''' any upstream completes
'''Cancels when''' downstream cancels
that
- (undocumented)combine
- (undocumented)<Out2,Out3,M> Graph<FlowShape<Out,Out3>,M> zipWithGraph(Graph<SourceShape<Out2>,M> that, scala.Function2<Out,Out2,Out3> combine)
FlowOps zipWithIndex()
'''Emits when''' upstream emits an element and is paired with their index
'''Backpressures when''' downstream backpressures
'''Completes when''' upstream completes
'''Cancels when''' downstream cancels
<U> FlowOps interleave(Graph<SourceShape<U>,?> that, int segmentSize)
Source
with elements of this Flow
.
It first emits segmentSize
number of elements from this flow to downstream, then - same amount for that
source, then repeat process.
Example:
Source(List(1, 2, 3)).interleave(List(4, 5, 6, 7), 2) // 1, 2, 4, 5, 3, 6, 7
After one of upstreams is complete than all the rest elements will be emitted from the second one
If it gets error from one of upstreams - stream completes with failure.
'''Emits when''' element is available from the currently consumed upstream
'''Backpressures when''' downstream backpressures. Signal to current
upstream, switch to next upstream when received segmentSize
elements
'''Completes when''' the Flow
and given Source
completes
'''Cancels when''' downstream cancels
that
- (undocumented)segmentSize
- (undocumented)<U,M> Graph<FlowShape<Out,U>,M> interleaveGraph(Graph<SourceShape<U>,M> that, int segmentSize)
<U,M> FlowOps merge(Graph<SourceShape<U>,M> that, boolean eagerComplete)
Source
to this Flow
, taking elements as they arrive from input streams,
picking randomly when several elements ready.
'''Emits when''' one of the inputs has an element available
'''Backpressures when''' downstream backpressures
'''Completes when''' all upstreams complete (eagerComplete=false) or one upstream completes (eagerComplete=true), default value is false
'''Cancels when''' downstream cancels
that
- (undocumented)eagerComplete
- (undocumented)<U,M> Graph<FlowShape<Out,U>,M> mergeGraph(Graph<SourceShape<U>,M> that, boolean eagerComplete)
<U,M> FlowOps mergeSorted(Graph<SourceShape<U>,M> that, scala.math.Ordering<U> ord)
Source
to this Flow
, taking elements as they arrive from input streams,
picking always the smallest of the available elements (waiting for one element from each side
to be available). This means that possible contiguity of the input streams is not exploited to avoid
waiting for elements, this merge will block when one of the inputs does not have more elements (and
does not complete).
'''Emits when''' all of the inputs have an element available
'''Backpressures when''' downstream backpressures
'''Completes when''' all upstreams complete
'''Cancels when''' downstream cancels
that
- (undocumented)ord
- (undocumented)<U,M> Graph<FlowShape<Out,U>,M> mergeSortedGraph(Graph<SourceShape<U>,M> that, scala.math.Ordering<U> ord)
<U,Mat2> FlowOps concat(Graph<SourceShape<U>,Mat2> that)
Source
to this Flow
, 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
is materialized together with this Flow and just kept
from producing elements by asserting back-pressure until its time comes.
If this Flow
gets upstream error - no elements from the given Source
will be pulled.
'''Emits when''' element is available from current stream or from the given Source
when current is completed
'''Backpressures when''' downstream backpressures
'''Completes when''' given Source
completes
'''Cancels when''' downstream cancels
that
- (undocumented)<U,Mat2> Graph<FlowShape<Out,U>,Mat2> concatGraph(Graph<SourceShape<U>,Mat2> that)
<U,Mat2> FlowOps prepend(Graph<SourceShape<U>,Mat2> that)
Source
to this Flow
, meaning that before elements
are generated from this Flow, the Source's elements will be produced until it
is exhausted, at which point Flow elements will start being produced.
Note that this Flow will be materialized together with the Source
and just kept
from producing elements by asserting back-pressure until its time comes.
If the given Source
gets upstream error - no elements from this Flow
will be pulled.
'''Emits when''' element is available from the given Source
or from current stream when the Source
is completed
'''Backpressures when''' downstream backpressures
'''Completes when''' this Flow
completes
'''Cancels when''' downstream cancels
that
- (undocumented)<U,Mat2> Graph<FlowShape<Out,U>,Mat2> prependGraph(Graph<SourceShape<U>,Mat2> that)
<U,Mat2> FlowOps orElse(Graph<SourceShape<U>,Mat2> secondary)
Note that this Flow will be materialized together with the Source
and just kept
from producing elements by asserting back-pressure until its time comes or it gets
cancelled.
On errors the stage is failed regardless of source of the error.
'''Emits when''' element is available from first stream or first stream closed without emitting any elements and an element is available from the second stream
'''Backpressures when''' downstream backpressures
'''Completes when''' the primary stream completes after emitting at least one element, when the primary stream completes without emitting and the secondary stream already has completed or when the secondary stream completes
'''Cancels when''' downstream cancels and additionally the alternative is cancelled as soon as an element passes by from this stream.
secondary
- (undocumented)<U,Mat2> Graph<FlowShape<Out,U>,Mat2> orElseGraph(Graph<SourceShape<U>,Mat2> secondary)
<Mat2> java.lang.Object to(Graph<SinkShape<Out>,Mat2> sink)
Flow
to a Sink
, concatenating the processing steps of both.
+----------------------------+
| Resulting Sink |
| |
| +------+ +------+ |
| | | | | |
In ~~> | flow | ~Out~> | sink | |
| | | | | |
| +------+ +------+ |
+----------------------------+
The materialized value of the combined Sink
will be the materialized
value of the current flow (ignoring the given Sink’s value), use
toMat
if a different strategy is needed.sink
- (undocumented)FlowOps alsoTo(Graph<SinkShape<Out>,?> that)
Sink
to this Flow
, meaning that elements that passes
through will also be sent to the Sink
.
'''Emits when''' element is available and demand exists both from the Sink and the downstream.
'''Backpressures when''' downstream or Sink backpressures
'''Completes when''' upstream completes
'''Cancels when''' downstream cancels
that
- (undocumented)FlowOps withAttributes(Attributes attr)
FlowOps addAttributes(Attributes attr)
FlowOps named(java.lang.String name)
FlowOps async()
Flow
.
If this is a SubFlow
(created e.g. by groupBy
), this creates an
asynchronous boundary around each materialized sub-flow, not the
super-flow. That way, the super-flow will communicate with sub-flows
asynchronously.
<T> FlowOps andThen(Stages.SymbolicStage<Out,T> op)