package javadsl
- Alphabetic
- By Inheritance
- javadsl
- AnyRef
- Any
- Hide All
- Show All
- Public
- Protected
Type Members
-  sealed final class AsPublisher extends Enum[AsPublisher]
-  final class BidiFlow[I1, O1, I2, O2, Mat] extends Graph[BidiShape[I1, O1, I2, O2], Mat]
-    trait DelayStrategy[T] extends AnyRefAllows to manage delay and can be stateful to compute delay for any sequence of elements, all elements go through nextDelay() updating state and returning delay for each element 
-   final  class Flow[In, Out, Mat] extends Graph[FlowShape[In, Out], Mat]A Flowis a set of stream processing steps that has one open input and one open output.
-   final  class FlowWithContext[In, CtxIn, Out, CtxOut, +Mat] extends GraphDelegate[FlowShape[Pair[In, CtxIn], Pair[Out, CtxOut]], Mat]A flow that provides operations which automatically propagate the context of an element. A flow that provides operations which automatically propagate the context of an element. Only a subset of common operations from Flow is supported. As an escape hatch you can use FlowWithContext.via to manually provide the context propagation for otherwise unsupported operations. An "empty" flow can be created by calling FlowWithContext[Ctx, T].
-   sealed final  class FramingTruncation extends Enum[FramingTruncation]Determines mode in which Framing operates. 
-   final  class JavaFlowSupport extends AnyRefFor use only with JDK 9+.For use only with JDK 9+.Provides support for java.util.concurrent.Flow.*interfaces which mirror the Reactive Streams interfaces fromorg.reactivestreams. See <a href="http//www.reactive-streams.org/">reactive-streams.org.
-   abstract  class RunnableGraph[+Mat] extends Graph[ClosedShape, Mat]Java API Java API Flow with attached input and output, can be executed. 
-   final  class Sink[In, Mat] extends Graph[SinkShape[In], Mat]Java API Java API A Sinkis a set of stream processing steps that has one open input. Can be used as aSubscriber
-    trait SinkQueue[T] extends AnyRefThis trait allows to have a queue as a sink for a stream. This trait allows to have a queue as a sink for a stream. A SinkQueue pulls data from stream with a backpressure mechanism. 
-    trait SinkQueueWithCancel[T] extends SinkQueue[T]This trait adds cancel support to SinkQueue. 
-   final  class Source[Out, Mat] extends Graph[SourceShape[Out], Mat]Java API Java API A Sourceis a set of stream processing steps that has one open output and an attached input. Can be used as aPublisher
-    trait SourceQueue[T] extends AnyRefThis trait allows to have a queue as a data source for some stream. 
-    trait SourceQueueWithComplete[T] extends SourceQueue[T]This trait adds completion support to SourceQueue. 
-   final  class SourceWithContext[Out, Ctx, +Mat] extends GraphDelegate[SourceShape[(Out, Ctx)], Mat]A source that provides operations which automatically propagate the context of an element. A source that provides operations which automatically propagate the context of an element. Only a subset of common operations from Source is supported. As an escape hatch you can use SourceWithContext#via to manually provide the context propagation for otherwise unsupported operations. Can be created by calling Source.asSourceWithContext 
-   final  class SubFlow[In, Out, Mat] extends AnyRefA “stream of streams” sub-flow of data elements, e.g. A “stream of streams” sub-flow of data elements, e.g. produced by groupBy. SubFlows cannot contribute to the super-flow’s materialized value since they are materialized later, during the runtime of the flow graph processing.
-   final  class SubSource[Out, Mat] extends AnyRefA “stream of streams” sub-flow of data elements, e.g. A “stream of streams” sub-flow of data elements, e.g. produced by groupBy. SubFlows cannot contribute to the super-flow’s materialized value since they are materialized later, during the runtime of the flow graph processing.
-  class Tcp extends Extension
-   final  class ThrottleControl extends AnyRefControl the throttle rate from the outside of the stream, or share a common throttle rate across several streams. 
Value Members
-  def combinerToScala[M1, M2, M](f: Function2[M1, M2, M]): (M1, M2) => M
-    object BalanceFan-out the stream to several streams. Fan-out the stream to several streams. Each upstream element is emitted to the first available downstream consumer. It will not shutdown until the subscriptions for at least two downstream subscribers have been established. Emits when any of the outputs stops backpressuring; emits the element to the first available output Backpressures when all of the outputs backpressure Completes when upstream completes Cancels when If eagerCancel is enabled: when any downstream cancels; otherwise: when all downstreams cancel 
-  object BidiFlow
-    object BroadcastFan-out the stream to several streams. Fan-out the stream to several streams. emitting each incoming upstream element to all downstream consumers. It will not shutdown until the subscriptions for at least two downstream subscribers have been established. Emits when all of the outputs stops backpressuring and there is an input element available Backpressures when any of the outputs backpressure Completes when upstream completes Cancels when If eagerCancel is enabled: when any downstream cancels; otherwise: when all downstreams cancel 
-    object BroadcastHubA BroadcastHub is a special streaming hub that is able to broadcast streamed elements to a dynamic set of consumers. A BroadcastHub is a special streaming hub that is able to broadcast streamed elements to a dynamic set of consumers. It consists of two parts, a Sink and a Source. The Sink broadcasts elements from a producer to the actually live consumers it has. Once the producer has been materialized, the Sink it feeds into returns a materialized value which is the corresponding Source. This Source can be materialized an arbitrary number of times, where each of the new materializations will receive their elements from the original Sink. 
-  object Compression
-    object ConcatTakes two streams and outputs an output stream formed from the two input streams by consuming one stream first emitting all of its elements, then consuming the second stream emitting all of its elements. Takes two streams and outputs an output stream formed from the two input streams by consuming one stream first emitting all of its elements, then consuming the second stream emitting all of its elements. Emits when the current stream has an element available; if the current input completes, it tries the next one Backpressures when downstream backpressures Completes when all upstreams complete Cancels when downstream cancels 
-  object DelayStrategy
-    object FileIOJava API: Factories to create sinks and sources from files 
-  object Flow
-  object FlowWithContext
-  object Framing
-  object GraphDSL extends GraphCreate
-    object JsonFramingProvides JSON framing operators that can separate valid JSON objects from incoming akka.util.ByteString objects. 
-  object Keep
-    object MergeMerge several streams, taking elements as they arrive from input streams (picking randomly when several have elements ready). Merge several streams, taking elements as they arrive from input streams (picking randomly when several have 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) Cancels when downstream cancels 
-    object MergeHubA MergeHub is a special streaming hub that is able to collect streamed elements from a dynamic set of producers. A MergeHub is a special streaming hub that is able to collect streamed elements from a dynamic set of producers. It consists of two parts, a Source and a Sink. The Source streams the element to a consumer from its merged inputs. Once the consumer has been materialized, the Source returns a materialized value which is the corresponding Sink. This Sink can then be materialized arbitrary many times, where each of the new materializations will feed its consumed elements to the original Source. 
-    object MergeLatestMergeLatest joins elements from N input streams into stream of lists of size N. MergeLatest joins elements from N input streams into stream of lists of size N. i-th element in list is the latest emitted element from i-th input stream. MergeLatest emits list for each element emitted from some input stream, but only after each stream emitted at least one element Emits when element is available from some input and each input emits at least one element from stream start Completes when all upstreams complete (eagerClose=false) or one upstream completes (eagerClose=true) Cancels when downstream cancels 
-    object MergePreferredMerge several streams, taking elements as they arrive from input streams (picking from preferred when several have elements ready). Merge several streams, taking elements as they arrive from input streams (picking from preferred when several have elements ready). Emits when one of the inputs has an element available, preferring a specified input if multiple have elements available Backpressures when downstream backpressures Completes when all upstreams complete (eagerComplete=false) or one upstream completes (eagerComplete=true) Cancels when downstream cancels 
-    object MergePrioritizedMerge several streams, taking elements as they arrive from input streams (picking from prioritized once when several have elements ready). Merge several streams, taking elements as they arrive from input streams (picking from prioritized once when several have elements ready). A MergePrioritizedhas oneoutport, one or more input port with their priorities.Emits when one of the inputs has an element available, preferring a input based on its priority if multiple have elements available Backpressures when downstream backpressures Completes when all upstreams complete (eagerComplete=false) or one upstream completes (eagerComplete=true), default value is falseCancels when downstream cancels A Broadcasthas oneinport and 2 or moreoutports.
-    object MergeSequenceTakes multiple streams whose elements in aggregate have a defined linear sequence with difference 1, starting at 0, and outputs a single stream containing these elements, in order. Takes multiple streams whose elements in aggregate have a defined linear sequence with difference 1, starting at 0, and outputs a single stream containing these elements, in order. That is, given a set of input streams with combined elements *ek*: *e0*, *e1*, *e2*, ..., *en* This will output a stream ordered by *k*. The elements in the input streams must already be sorted according to the sequence. The input streams do not need to be linear, but the aggregate stream must be linear, no element *k* may be skipped or duplicated, either of these conditions will cause the stream to fail. The typical use case for this is to merge a partitioned stream back together while maintaining order. This can be achieved by first using zipWithIndexon the input stream, then partitioning using a Partition fanout, and then maintaining the index through the processing of each partition before bringing together with this stage.Emits when one of the upstreams has the next expected element in the sequence available. Backpressures when downstream backpressures Completes when all upstreams complete Cancels when downstream cancels 
-    object PartitionFan-out the stream to several streams. Fan-out the stream to several streams. emitting an incoming upstream element to one downstream consumer according to the partitioner function applied to the element Adheres to the ActorAttributes.SupervisionStrategy attribute. Emits when all of the outputs stops backpressuring and there is an input element available Backpressures when one of the outputs backpressure Completes when upstream completes Cancels when when any (eagerCancel=true) or all (eagerCancel=false) of the downstreams cancel 
-    object PartitionHubA PartitionHubis a special streaming hub that is able to route streamed elements to a dynamic set of consumers.A PartitionHubis a special streaming hub that is able to route streamed elements to a dynamic set of consumers. It consists of two parts, a Sink and a Source. The Sink e elements from a producer to the actually live consumers it has. The selection of consumer is done with a function. Each element can be routed to only one consumer. Once the producer has been materialized, the Sink it feeds into returns a materialized value which is the corresponding Source. This Source can be materialized an arbitrary number of times, where each of the new materializations will receive their elements from the original Sink.
-    object RestartFlowA RestartFlow wraps a Flow that gets restarted when it completes or fails. A RestartFlow wraps a Flow that gets restarted when it completes or fails. They are useful for graphs that need to run for longer than the Flow can necessarily guarantee it will, for example, for Flow streams that depend on a remote server that may crash or become partitioned. The RestartFlow ensures that the graph can continue running while the Flow restarts. 
-    object RestartSinkA RestartSink wraps a Sink that gets restarted when it completes or fails. A RestartSink wraps a Sink that gets restarted when it completes or fails. They are useful for graphs that need to run for longer than the Sink can necessarily guarantee it will, for example, for Sink streams that depend on a remote server that may crash or become partitioned. The RestartSink ensures that the graph can continue running while the Sink restarts. 
-    object RestartSourceA RestartSource wraps a Source that gets restarted when it completes or fails. A RestartSource wraps a Source that gets restarted when it completes or fails. They are useful for graphs that need to run for longer than the Source can necessarily guarantee it will, for example, for Source streams that depend on a remote server that may crash or become partitioned. The RestartSource ensures that the graph can continue running while the Source restarts. 
-    object RestartSourceWithContextA RestartSourceWithContext wraps a SourceWithContext that gets restarted when it completes or fails. A RestartSourceWithContext wraps a SourceWithContext that gets restarted when it completes or fails. They are useful for graphs that need to run for longer than the SourceWithContext can necessarily guarantee it will, e.g. for SourceWithContext streams that depend on a remote service to which connectivity may be lost (crash or partition). The RestartSourceWithContext ensures that the graph can continue running while the SourceWithContext restarts. 
-  object RetryFlow
-  object RunnableGraph
-    object SinkJava API 
-  object SinkQueueWithCancel
-    object SourceJava API 
-  object SourceQueueWithComplete
-  object SourceWithContext
-    object StreamConvertersConverters for interacting with the blocking java.iostreams APIs and Java 8 Streams
-    object StreamRefsFactories for creating stream refs. 
-  object SubFlow
-    object SubSource* Upcast a stream of elements to a stream of supertypes of that element. * Upcast a stream of elements to a stream of supertypes of that element. Useful in combination with fan-in operators where you do not want to pay the cost of casting each element in a map.
-    object TLSStream cipher support based upon JSSE. Stream cipher support based upon JSSE. The underlying SSLEngine has four ports: plaintext input/output and ciphertext input/output. These are modeled as a akka.stream.BidiShape element for use in stream topologies, where the plaintext ports are on the left hand side of the shape and the ciphertext ports on the right hand side. Configuring JSSE is a rather complex topic, please refer to the JDK platform documentation or the excellent user guide that is part of the Play Framework documentation. The philosophy of this integration into Akka Streams is to expose all knobs and dials to client code and therefore not limit the configuration possibilities. In particular the client code will have to provide the SSLEngine, which is typically created from a SSLContext. Handshake parameters and other parameters are defined when creating the SSLEngine. IMPORTANT NOTE The TLS specification until version 1.2 did not permit half-closing of the user data session that it transports—to be precise a half-close will always promptly lead to a full close. This means that canceling the plaintext output or completing the plaintext input of the SslTls operator will lead to full termination of the secure connection without regard to whether bytes are remaining to be sent or received, respectively. Especially for a client the common idiom of attaching a finite Source to the plaintext input and transforming the plaintext response bytes coming out will not work out of the box due to early termination of the connection. For this reason there is a parameter that determines whether the SslTls operator shall ignore completion and/or cancellation events, and the default is to ignore completion (in view of the client–server scenario). In order to terminate the connection the client will then need to cancel the plaintext output as soon as all expected bytes have been received. When ignoring both types of events the operator will shut down once both events have been received. See also TLSClosing. For now, half-closing is also not supported with TLS 1.3 where the spec allows it. 
-    object TLSPlaceboThis object holds simple wrapping akka.stream.scaladsl.BidiFlow implementations that can be used instead of TLS when no encryption is desired. This object holds simple wrapping akka.stream.scaladsl.BidiFlow implementations that can be used instead of TLS when no encryption is desired. The flows will just adapt the message protocol by wrapping into SessionBytes and unwrapping SendBytes. 
-  object Tcp extends ExtensionId[Tcp] with ExtensionIdProvider
-    object UnzipTakes a stream of pair elements and splits each pair to two output streams. Takes a stream of pair elements and splits each pair to two output streams. An Unziphas oneinport and oneleftand onerightoutput port.Emits when all of the outputs stops backpressuring and there is an input element available Backpressures when any of the outputs backpressures Completes when upstream completes Cancels when any downstream cancels 
-    object UnzipWithSplit one stream into several streams using a splitting function. Split one stream into several streams using a splitting function. Emits when all of the outputs stops backpressuring and there is an input element available Backpressures when any of the outputs backpressures Completes when upstream completes Cancels when any downstream cancels 
-    object ZipCombine the elements of 2 streams into a stream of tuples. Combine the elements of 2 streams into a stream of tuples. A Ziphas aleftand arightinput port and oneoutportEmits when all of the inputs has an element available Backpressures when downstream backpressures Completes when any upstream completes Cancels when downstream cancels 
-    object ZipLatestCombine the elements of 2 streams into a stream of tuples, picking always the latest element of each. Combine the elements of 2 streams into a stream of tuples, picking always the latest element of each. A Ziphas aleftand arightinput port and oneoutportEmits when all of the inputs have at least an element available, and then each time an element becomes available on either of the inputs Backpressures when downstream backpressures Completes when any upstream completes Cancels when downstream cancels 
-    object ZipLatestWithCombine the elements of multiple streams into a stream of combined elements using a combiner function, picking always the latest of the elements of each source. Combine the elements of multiple streams into a stream of combined elements using a combiner function, picking always the latest of the elements of each source. No element is emitted until at least one element from each Source becomes available. Whenever a new element appears, the zipping function is invoked with a tuple containing the new element and the other last seen elements. Emits when all of the inputs have at least an element available, and then each time an element becomes available on either of the inputs Backpressures when downstream backpressures Completes when any of the upstreams completes Cancels when downstream cancels 
-    object ZipNCombine the elements of multiple streams into a stream of lists. Combine the elements of multiple streams into a stream of lists. A ZipNhas aninput ports and oneoutportEmits when all of the inputs has an element available Backpressures when downstream backpressures Completes when any upstream completes Cancels when downstream cancels 
-    object ZipWithCombine the elements of multiple streams into a stream of combined elements using a combiner function. Combine the elements of multiple streams into a stream of combined elements using a combiner function. Emits when all of the inputs has an element available Backpressures when downstream backpressures Completes when any upstream completes Cancels when downstream cancels 
-    object ZipWithNCombine the elements of multiple streams into a stream of lists using a combiner function. Combine the elements of multiple streams into a stream of lists using a combiner function. A ZipWithNhas aninput ports and oneoutportEmits when all of the inputs has an element available Backpressures when downstream backpressures Completes when any upstream completes Cancels when downstream cancels