Package | Description |
---|---|
reactor.bus |
Hold the required abstraction to enable Event Driven Programming with Reactor.
|
reactor.core.reactivestreams | |
reactor.fn |
This package contains the foundational abstractions on which Reactor's functional and reactive components are
built.
|
reactor.groovy.ext | |
reactor.groovy.support | |
reactor.io.codec |
Components to handle encoding and decoding of objects into
Buffers . |
reactor.io.codec.compress | |
reactor.io.codec.json |
Encoding and decoding using the JSON format.
|
reactor.io.codec.kryo | |
reactor.io.codec.protobuf | |
reactor.io.net |
Reactive network components are located in this package scope implementing the following exposed contract:
A
ReactorPeer NetServer/NetClient is a Publisher of
ReactorChannel that are themselves Publisher of input data. |
reactor.io.net.codec.syslog |
Decoding using the syslog format.
|
reactor.rx |
Streams are reactive components derived from Reactive Extensions and implementing Reactive Streams specification.
|
reactor.rx.action.combination | |
reactor.rx.action.control | |
reactor.rx.action.error | |
reactor.rx.action.filter | |
reactor.rx.action.terminal | |
reactor.rx.action.transformation | |
reactor.rx.stream |
Modifier and Type | Method and Description |
---|---|
Function<E,V> |
EventBus.ReplyToConsumer.getDelegate() |
Modifier and Type | Method and Description |
---|---|
<T> EventBus |
EventBus.notify(org.reactivestreams.Publisher<? extends T> source,
Function<? super T,?> keyMapper)
Pass values accepted by this
Stream into the given Bus , notifying with the given key. |
<T extends Event<?>,V> |
EventBus.receive(Selector sel,
Function<T,V> fn)
|
Modifier and Type | Method and Description |
---|---|
static <T,C> org.reactivestreams.Publisher<T> |
PublisherFactory.create(BiConsumer<Long,SubscriberWithContext<T,C>> requestConsumer,
Function<org.reactivestreams.Subscriber<? super T>,C> contextFactory)
Create a
Publisher reacting on requests with the passed BiConsumer
The argument contextFactory is executed once by new subscriber to generate a context shared by every
request calls. |
static <T,C> org.reactivestreams.Publisher<T> |
PublisherFactory.create(BiConsumer<Long,SubscriberWithContext<T,C>> requestConsumer,
Function<org.reactivestreams.Subscriber<? super T>,C> contextFactory,
Consumer<C> shutdownConsumer)
Create a
Publisher reacting on requests with the passed BiConsumer . |
static <T,C> org.reactivestreams.Subscriber<T> |
SubscriberFactory.create(Function<org.reactivestreams.Subscription,C> subscriptionHandler,
BiConsumer<T,SubscriptionWithContext<C>> dataConsumer)
Create a
Subscriber reacting onSubscribe and onNext, eventually sharing a context. |
static <T,C> org.reactivestreams.Subscriber<T> |
SubscriberFactory.create(Function<org.reactivestreams.Subscription,C> subscriptionHandler,
BiConsumer<T,SubscriptionWithContext<C>> dataConsumer,
BiConsumer<Throwable,C> errorConsumer)
Create a
Subscriber reacting onNext, onError. |
static <T,C> org.reactivestreams.Subscriber<T> |
SubscriberFactory.create(Function<org.reactivestreams.Subscription,C> subscriptionHandler,
BiConsumer<T,SubscriptionWithContext<C>> dataConsumer,
BiConsumer<Throwable,C> errorConsumer,
Consumer<C> completeConsumer)
Create a
Subscriber reacting onNext, onSubscribe, onError, onComplete with the passed BiConsumer . |
static <T,C> org.reactivestreams.Publisher<T> |
PublisherFactory.forEach(Consumer<SubscriberWithContext<T,C>> requestConsumer,
Function<org.reactivestreams.Subscriber<? super T>,C> contextFactory)
|
static <T,C> org.reactivestreams.Publisher<T> |
PublisherFactory.forEach(Consumer<SubscriberWithContext<T,C>> requestConsumer,
Function<org.reactivestreams.Subscriber<? super T>,C> contextFactory,
Consumer<C> shutdownConsumer)
|
static <I,O> org.reactivestreams.Publisher<O> |
PublisherFactory.intercept(org.reactivestreams.Publisher<? extends I> source,
Function<org.reactivestreams.Subscriber<? super O>,SubscriberBarrier<I,O>> barrierProvider)
Create a
Publisher intercepting all source signals with a SubscriberBarrier per Subscriber
provided by the given barrierProvider. |
Modifier and Type | Method and Description |
---|---|
static <T,V> Function<T,V> |
Functions.function(Callable<V> c)
Deprecated.
|
static <LEFT,RIGHT,V> |
Functions.functionFrom(BiFunction<LEFT,RIGHT,V> pairFunction)
Deprecated.
Wrap a given
BiFunction that applies transformation to a Tuple2 into a Function Tuple2. |
Modifier and Type | Method and Description |
---|---|
static <LEFT,RIGHT,V> |
Functions.pairFrom(Function<Tuple2<LEFT,RIGHT>,V> function)
Deprecated.
Wrap a given
Function that applies transformation to a Tuple2 into a PairFunction. |
Modifier and Type | Method and Description |
---|---|
static <T,V> void |
BusExtensions.call(Function<T,V> selfType,
T value) |
static <T,V> Stream<V> |
StreamExtensions.or(Promise<T> selfType,
Function<T,V> other) |
static <T,V> Stream<V> |
StreamExtensions.or(Stream<T> selfType,
Function<T,V> other) |
Modifier and Type | Class and Description |
---|---|
class |
ClosureEventFunction<K,V> |
class |
ClosureFunction<K,V> |
class |
ClosureReduce<T,V> |
Modifier and Type | Class and Description |
---|---|
class |
BufferCodec<IN,OUT>
Implementations of a BufferCodec are codec manipulating Buffer sources
|
class |
ByteArrayCodec
|
class |
Codec<SRC,IN,OUT>
Implementations of a Codec are responsible for decoding a
SRC into an
instance of IN and passing that to the given Consumer . |
class |
DelimitedCodec<IN,OUT>
|
class |
FrameCodec
Codec for decoding data into length-field-based Frames . |
class |
JavaSerializationCodec<T>
Codec to transform Java objects into Buffers and visa-versa. |
class |
LengthFieldCodec<IN,OUT>
A codec that uses a length-field at the start of each chunk to denote the chunk's size.
|
class |
PassThroughCodec<SRC>
A simple
Codec that uses the source object as both input and output. |
class |
SerializationCodec<E,IN,OUT>
Abstract base class for
Codec Codecs that perform serialization of objects. |
class |
StringCodec |
class |
StringCodec.StringEncoder |
Modifier and Type | Method and Description |
---|---|
Function<SRC,IN> |
Codec.decoder()
Provide the caller with a decoder to turn a source object into an instance of the input
type.
|
Function<Buffer,byte[]> |
ByteArrayCodec.decoder(Consumer<byte[]> next) |
Function<Buffer,Frame> |
FrameCodec.decoder(Consumer<Frame> next) |
abstract Function<SRC,IN> |
Codec.decoder(Consumer<IN> next)
Provide the caller with a decoder to turn a source object into an instance of the input
type.
|
Function<Buffer,IN> |
SerializationCodec.decoder(Consumer<IN> next) |
Function<Buffer,IN> |
LengthFieldCodec.decoder(Consumer<IN> next) |
Function<Buffer,IN> |
DelimitedCodec.decoder(Consumer<IN> next) |
Function<SRC,SRC> |
PassThroughCodec.decoder(Consumer<SRC> next) |
Function<Buffer,String> |
StringCodec.decoder(Consumer<String> next) |
Function<Buffer,T> |
JavaSerializationCodec.decoder(Consumer<T> next) |
protected abstract Function<byte[],IN> |
SerializationCodec.deserializer(E engine,
Class<IN> type,
Consumer<IN> next) |
Function<String,Buffer> |
StringCodec.encoder() |
Function<OUT,SRC> |
Codec.encoder()
Provide the caller with an encoder to turn an output object into an instance of the source
type.
|
protected abstract Function<OUT,byte[]> |
SerializationCodec.serializer(E engine) |
Modifier and Type | Class and Description |
---|---|
class |
CompressionCodec<IN,OUT> |
class |
GzipCodec<IN,OUT> |
class |
SnappyCodec<IN,OUT> |
Modifier and Type | Method and Description |
---|---|
Function<Buffer,IN> |
CompressionCodec.decoder(Consumer<IN> next) |
Modifier and Type | Class and Description |
---|---|
class |
JacksonJsonCodec<IN,OUT> |
class |
JsonCodec<IN,OUT>
A codec for decoding JSON into Java objects and encoding Java objects into JSON.
|
Modifier and Type | Method and Description |
---|---|
Function<Buffer,IN> |
JsonCodec.decoder(Consumer<IN> next) |
protected Function<byte[],IN> |
JacksonJsonCodec.deserializer(com.fasterxml.jackson.databind.ObjectMapper engine,
Class<IN> type,
Consumer<IN> next) |
protected Function<OUT,byte[]> |
JacksonJsonCodec.serializer(com.fasterxml.jackson.databind.ObjectMapper engine) |
Modifier and Type | Class and Description |
---|---|
class |
KryoCodec<IN,OUT> |
class |
KryoPoolCodec<IN,OUT> |
Modifier and Type | Method and Description |
---|---|
protected Function<byte[],IN> |
KryoCodec.deserializer(com.esotericsoftware.kryo.Kryo engine,
Class<IN> type,
Consumer<IN> next) |
protected Function<byte[],IN> |
KryoPoolCodec.deserializer(com.esotericsoftware.kryo.pool.KryoPool engine,
Class<IN> type,
Consumer<IN> next) |
protected Function<OUT,byte[]> |
KryoCodec.serializer(com.esotericsoftware.kryo.Kryo engine) |
protected Function<OUT,byte[]> |
KryoPoolCodec.serializer(com.esotericsoftware.kryo.pool.KryoPool engine) |
Modifier and Type | Class and Description |
---|---|
class |
ProtobufCodec<IN,OUT> |
Modifier and Type | Method and Description |
---|---|
protected Function<byte[],IN> |
ProtobufCodec.deserializer(Map<Class<?>,com.google.protobuf.Message> messages,
Class<IN> type,
Consumer<IN> next) |
protected Function<OUT,byte[]> |
ProtobufCodec.serializer(Map<Class<?>,com.google.protobuf.Message> messages) |
Modifier and Type | Interface and Description |
---|---|
static interface |
NetStreams.HttpClientFactory<IN,OUT> |
static interface |
NetStreams.HttpServerFactory<IN,OUT> |
static interface |
NetStreams.TcpClientFactory<IN,OUT> |
static interface |
NetStreams.TcpServerFactory<IN,OUT> |
static interface |
NetStreams.UdpServerFactory<IN,OUT> |
interface |
ReactorChannelHandler<IN,OUT,CONN extends ReactorChannel<IN,OUT>>
A
ReactorChannel callback that is attached on ReactorPeer or ReactorClient initialization and receives
all connected ReactorChannel . |
Modifier and Type | Field and Description |
---|---|
static Function |
Spec.NOOP_DECODER |
Modifier and Type | Method and Description |
---|---|
Function<Buffer,IN> |
ChannelStream.getDecoder() |
Function<OUT,Buffer> |
ChannelStream.getEncoder() |
Modifier and Type | Method and Description |
---|---|
static <IN,OUT> HttpClient<IN,OUT> |
NetStreams.httpClient(Class<? extends HttpClient> clientFactory,
Function<? super Spec.HttpClientSpec<IN,OUT>,? extends Spec.HttpClientSpec<IN,OUT>> configuringFunction)
Bind a new HTTP client to the specified connect address and port.
|
static <IN,OUT> HttpClient<IN,OUT> |
NetStreams.httpClient(Function<? super Spec.HttpClientSpec<IN,OUT>,? extends Spec.HttpClientSpec<IN,OUT>> configuringFunction)
Bind a new HTTP client to the specified connect address and port.
|
static <IN,OUT> HttpServer<IN,OUT> |
NetStreams.httpServer(Class<? extends HttpServer> serverFactory,
Function<? super Spec.HttpServerSpec<IN,OUT>,? extends Spec.HttpServerSpec<IN,OUT>> configuringFunction) |
static <IN,OUT> HttpServer<IN,OUT> |
NetStreams.httpServer(Function<? super Spec.HttpServerSpec<IN,OUT>,? extends Spec.HttpServerSpec<IN,OUT>> configuringFunction)
Build a Netty HTTP Server with the passed factory
|
static <IN,OUT> TcpClient<IN,OUT> |
NetStreams.tcpClient(Class<? extends TcpClient> clientFactory,
Function<? super Spec.TcpClientSpec<IN,OUT>,? extends Spec.TcpClientSpec<IN,OUT>> configuringFunction)
Bind a new TCP client to the specified connect address and port.
|
static <IN,OUT> TcpClient<IN,OUT> |
NetStreams.tcpClient(Function<? super Spec.TcpClientSpec<IN,OUT>,? extends Spec.TcpClientSpec<IN,OUT>> configuringFunction)
Bind a new TCP client to the specified connect address and port.
|
static <IN,OUT> TcpServer<IN,OUT> |
NetStreams.tcpServer(Class<? extends TcpServer> serverFactory,
Function<? super Spec.TcpServerSpec<IN,OUT>,? extends Spec.TcpServerSpec<IN,OUT>> configuringFunction)
Bind a new TCP server to the specified bind address and port.
|
static <IN,OUT> TcpServer<IN,OUT> |
NetStreams.tcpServer(Function<? super Spec.TcpServerSpec<IN,OUT>,? extends Spec.TcpServerSpec<IN,OUT>> configuringFunction)
Bind a new TCP server to the specified bind address and port.
|
static <IN,OUT> DatagramServer<IN,OUT> |
NetStreams.udpServer(Class<? extends DatagramServer> serverFactory,
Function<? super Spec.DatagramServerSpec<IN,OUT>,? extends Spec.DatagramServerSpec<IN,OUT>> configuringFunction)
Bind a new UDP server to the specified bind address and port.
|
static <IN,OUT> DatagramServer<IN,OUT> |
NetStreams.udpServer(Function<? super Spec.DatagramServerSpec<IN,OUT>,? extends Spec.DatagramServerSpec<IN,OUT>> configuringFunction)
Bind a new UDP server to the specified bind address and port.
|
Modifier and Type | Class and Description |
---|---|
class |
SyslogCodec
A coded for consuming syslog messages.
|
Modifier and Type | Method and Description |
---|---|
Function<Buffer,SyslogMessage> |
SyslogCodec.decoder(Consumer<SyslogMessage> next) |
Modifier and Type | Method and Description |
---|---|
Control |
Stream.adaptiveConsume(Consumer<? super O> consumer,
Function<Stream<Long>,? extends org.reactivestreams.Publisher<? extends Long>> requestMapper)
|
Control |
Stream.adaptiveConsumeOn(Dispatcher dispatcher,
Consumer<? super O> consumer,
Function<Stream<Long>,? extends org.reactivestreams.Publisher<? extends Long>> requestMapper)
|
Control |
Stream.batchConsume(Consumer<? super O> consumer,
Function<Long,? extends Long> requestMapper)
|
Control |
Stream.batchConsumeOn(Dispatcher dispatcher,
Consumer<? super O> consumer,
Function<Long,? extends Long> requestMapper)
|
static <TUPLE extends Tuple,V> |
Streams.combineLatest(List<? extends org.reactivestreams.Publisher<?>> sources,
Function<TUPLE,? extends V> combinator)
Build a Stream whose data are generated by the combination of the most recent published values from
all publishers.
|
static <E,TUPLE extends Tuple,V> |
Streams.combineLatest(org.reactivestreams.Publisher<? extends org.reactivestreams.Publisher<E>> sources,
Function<TUPLE,? extends V> combinator)
Build a Stream whose data are generated by the combination of the most recent published values from
all publishers.
|
static <T1,T2,V> Stream<V> |
Streams.combineLatest(org.reactivestreams.Publisher<? extends T1> source1,
org.reactivestreams.Publisher<? extends T2> source2,
Function<Tuple2<T1,T2>,? extends V> combinator)
Build a Stream whose data are generated by the combination of the most recent published values from
all publishers.
|
static <T1,T2,T3,V> |
Streams.combineLatest(org.reactivestreams.Publisher<? extends T1> source1,
org.reactivestreams.Publisher<? extends T2> source2,
org.reactivestreams.Publisher<? extends T3> source3,
Function<Tuple3<T1,T2,T3>,? extends V> combinator)
Build a Stream whose data are generated by the combination of the most recent published values from
all publishers.
|
static <T1,T2,T3,T4,V> |
Streams.combineLatest(org.reactivestreams.Publisher<? extends T1> source1,
org.reactivestreams.Publisher<? extends T2> source2,
org.reactivestreams.Publisher<? extends T3> source3,
org.reactivestreams.Publisher<? extends T4> source4,
Function<Tuple4<T1,T2,T3,T4>,V> combinator)
Build a Stream whose data are generated by the combination of the most recent published values from
all publishers.
|
static <T1,T2,T3,T4,T5,V> |
Streams.combineLatest(org.reactivestreams.Publisher<? extends T1> source1,
org.reactivestreams.Publisher<? extends T2> source2,
org.reactivestreams.Publisher<? extends T3> source3,
org.reactivestreams.Publisher<? extends T4> source4,
org.reactivestreams.Publisher<? extends T5> source5,
Function<Tuple5<T1,T2,T3,T4,T5>,V> combinator)
Build a Stream whose data are generated by the combination of the most recent published values from
all publishers.
|
static <T1,T2,T3,T4,T5,T6,V> |
Streams.combineLatest(org.reactivestreams.Publisher<? extends T1> source1,
org.reactivestreams.Publisher<? extends T2> source2,
org.reactivestreams.Publisher<? extends T3> source3,
org.reactivestreams.Publisher<? extends T4> source4,
org.reactivestreams.Publisher<? extends T5> source5,
org.reactivestreams.Publisher<? extends T6> source6,
Function<Tuple6<T1,T2,T3,T4,T5,T6>,V> combinator)
Build a Stream whose data are generated by the combination of the most recent published values from
all publishers.
|
static <T1,T2,T3,T4,T5,T6,T7,V> |
Streams.combineLatest(org.reactivestreams.Publisher<? extends T1> source1,
org.reactivestreams.Publisher<? extends T2> source2,
org.reactivestreams.Publisher<? extends T3> source3,
org.reactivestreams.Publisher<? extends T4> source4,
org.reactivestreams.Publisher<? extends T5> source5,
org.reactivestreams.Publisher<? extends T6> source6,
org.reactivestreams.Publisher<? extends T7> source7,
Function<Tuple7<T1,T2,T3,T4,T5,T6,T7>,V> combinator)
Build a Stream whose data are generated by the combination of the most recent published values from
all publishers.
|
static <T1,T2,T3,T4,T5,T6,T7,T8,V> |
Streams.combineLatest(org.reactivestreams.Publisher<? extends T1> source1,
org.reactivestreams.Publisher<? extends T2> source2,
org.reactivestreams.Publisher<? extends T3> source3,
org.reactivestreams.Publisher<? extends T4> source4,
org.reactivestreams.Publisher<? extends T5> source5,
org.reactivestreams.Publisher<? extends T6> source6,
org.reactivestreams.Publisher<? extends T7> source7,
org.reactivestreams.Publisher<? extends T8> source8,
Function<Tuple8<T1,T2,T3,T4,T5,T6,T7,T8>,? extends V> combinator)
Build a Stream whose data are generated by the combination of the most recent published values from
all publishers.
|
<V> Stream<V> |
Stream.concatMap(Function<? super O,org.reactivestreams.Publisher<? extends V>> fn)
Assign the given
Function to transform the incoming value T into a Stream<O,V> and pass
it into another Stream . |
static <T,C> Stream<T> |
Streams.createWith(BiConsumer<Long,SubscriberWithContext<T,C>> requestConsumer,
Function<org.reactivestreams.Subscriber<? super T>,C> contextFactory)
Create a
Stream reacting on requests with the passed BiConsumer
The argument contextFactory is executed once by new subscriber to generate a context shared by every
request calls. |
static <T,C> Stream<T> |
Streams.createWith(BiConsumer<Long,SubscriberWithContext<T,C>> requestConsumer,
Function<org.reactivestreams.Subscriber<? super T>,C> contextFactory,
Consumer<C> shutdownConsumer)
Create a
Stream reacting on requests with the passed BiConsumer . |
<V> Stream<O> |
Stream.distinct(Function<? super O,? extends V> keySelector)
Create a new
Stream that filters in only values having distinct keys computed by function |
<V> Stream<O> |
Stream.distinctUntilChanged(Function<? super O,? extends V> keySelector)
Create a new
Stream that filters out consecutive values having equal keys computed by function |
<V> Stream<V> |
Stream.flatMap(Function<? super O,? extends org.reactivestreams.Publisher<? extends V>> fn)
Assign the given
Function to transform the incoming value T into a Stream<O,V> and pass
it into another Stream . |
<V> Promise<V> |
Promise.flatMap(Function<? super O,? extends org.reactivestreams.Publisher<? extends V>> transformation)
Assign a
Function that will either be invoked later, when the Promise is successfully completed
with
a value, or, if this Promise has already been fulfilled, is immediately scheduled to be executed on the
current Dispatcher . |
<K> Stream<GroupedStream<K,O>> |
Stream.groupBy(Function<? super O,? extends K> keyMapper)
Re-route incoming values into a dynamically created
Stream for each unique key evaluated by the
{param keyMapper}. |
<V> Stream<V> |
Stream.map(Function<? super O,? extends V> fn)
Assign the given
Function to transform the incoming value T into a V and pass it into
another Stream . |
<V> Promise<V> |
Promise.map(Function<? super O,V> transformation)
Assign a
Function that will either be invoked later, when the Promise is successfully completed
with
a value, or, if this Promise has already been fulfilled, is immediately scheduled to be executed on the
current Dispatcher . |
<E extends Throwable> |
Stream.onErrorReturn(Class<E> exceptionType,
Function<E,? extends O> fallback)
Produce a default value when exceptions of the given type occur, otherwise propagate the error.
|
Stream<O> |
Stream.onErrorReturn(Function<Throwable,? extends O> fallback)
Produce a default value if any exception occurs.
|
Stream<O> |
Stream.repeatWhen(Function<? super Stream<? extends Long>,? extends org.reactivestreams.Publisher<?>> backOffStream)
Create a new
Stream which will re-subscribe its oldest parent-child stream pair if the backOff stream
produced by the passed mapper emits any next signal. |
Stream<O> |
Stream.requestWhen(Function<? super Stream<? extends Long>,? extends org.reactivestreams.Publisher<? extends Long>> throttleStream)
Request the parent stream every time the passed throttleStream signals a Long request volume.
|
Stream<O> |
Stream.retryWhen(Function<? super Stream<? extends Throwable>,? extends org.reactivestreams.Publisher<?>> backOffStream)
Create a new
Stream which will re-subscribe its oldest parent-child stream pair if the backOff stream
produced by the passed mapper emits any next data or complete signal. |
<V> Stream<V> |
Stream.switchMap(Function<? super O,org.reactivestreams.Publisher<? extends V>> fn)
Assign the given
Function to transform the incoming value T into a Stream<O,V> and pass
it into another Stream . |
<V> Stream<V> |
Stream.zip(Function<TupleN,? extends V> zipper)
|
static <TUPLE extends Tuple,V> |
Streams.zip(List<? extends org.reactivestreams.Publisher<?>> sources,
Function<TUPLE,? extends V> combinator)
Build a Stream whose data are generated by the passed publishers.
|
static <E,TUPLE extends Tuple,V> |
Streams.zip(org.reactivestreams.Publisher<? extends org.reactivestreams.Publisher<E>> sources,
Function<TUPLE,? extends V> combinator)
Build a Stream whose data are generated by the passed publishers.
|
static <T1,T2,V> Stream<V> |
Streams.zip(org.reactivestreams.Publisher<? extends T1> source1,
org.reactivestreams.Publisher<? extends T2> source2,
Function<Tuple2<T1,T2>,? extends V> combinator)
Build a Stream whose data are generated by the passed publishers.
|
static <T1,T2,T3,V> |
Streams.zip(org.reactivestreams.Publisher<? extends T1> source1,
org.reactivestreams.Publisher<? extends T2> source2,
org.reactivestreams.Publisher<? extends T3> source3,
Function<Tuple3<T1,T2,T3>,? extends V> combinator)
Build a Stream whose data are generated by the passed publishers.
|
static <T1,T2,T3,T4,V> |
Streams.zip(org.reactivestreams.Publisher<? extends T1> source1,
org.reactivestreams.Publisher<? extends T2> source2,
org.reactivestreams.Publisher<? extends T3> source3,
org.reactivestreams.Publisher<? extends T4> source4,
Function<Tuple4<T1,T2,T3,T4>,V> combinator)
Build a Stream whose data are generated by the passed publishers.
|
static <T1,T2,T3,T4,T5,V> |
Streams.zip(org.reactivestreams.Publisher<? extends T1> source1,
org.reactivestreams.Publisher<? extends T2> source2,
org.reactivestreams.Publisher<? extends T3> source3,
org.reactivestreams.Publisher<? extends T4> source4,
org.reactivestreams.Publisher<? extends T5> source5,
Function<Tuple5<T1,T2,T3,T4,T5>,V> combinator)
Build a Stream whose data are generated by the passed publishers.
|
static <T1,T2,T3,T4,T5,T6,V> |
Streams.zip(org.reactivestreams.Publisher<? extends T1> source1,
org.reactivestreams.Publisher<? extends T2> source2,
org.reactivestreams.Publisher<? extends T3> source3,
org.reactivestreams.Publisher<? extends T4> source4,
org.reactivestreams.Publisher<? extends T5> source5,
org.reactivestreams.Publisher<? extends T6> source6,
Function<Tuple6<T1,T2,T3,T4,T5,T6>,V> combinator)
Build a Stream whose data are generated by the passed publishers.
|
static <T1,T2,T3,T4,T5,T6,T7,V> |
Streams.zip(org.reactivestreams.Publisher<? extends T1> source1,
org.reactivestreams.Publisher<? extends T2> source2,
org.reactivestreams.Publisher<? extends T3> source3,
org.reactivestreams.Publisher<? extends T4> source4,
org.reactivestreams.Publisher<? extends T5> source5,
org.reactivestreams.Publisher<? extends T6> source6,
org.reactivestreams.Publisher<? extends T7> source7,
Function<Tuple7<T1,T2,T3,T4,T5,T6,T7>,V> combinator)
Build a Stream whose data are generated by the passed publishers.
|
static <T1,T2,T3,T4,T5,T6,T7,T8,V> |
Streams.zip(org.reactivestreams.Publisher<? extends T1> source1,
org.reactivestreams.Publisher<? extends T2> source2,
org.reactivestreams.Publisher<? extends T3> source3,
org.reactivestreams.Publisher<? extends T4> source4,
org.reactivestreams.Publisher<? extends T5> source5,
org.reactivestreams.Publisher<? extends T6> source6,
org.reactivestreams.Publisher<? extends T7> source7,
org.reactivestreams.Publisher<? extends T8> source8,
Function<Tuple8<T1,T2,T3,T4,T5,T6,T7,T8>,? extends V> combinator)
Build a Stream whose data are generated by the passed publishers.
|
<T2,V> Stream<V> |
Stream.zipWith(Iterable<? extends T2> iterable,
Function<Tuple2<O,T2>,V> zipper)
|
<T2,V> Stream<V> |
Stream.zipWith(org.reactivestreams.Publisher<? extends T2> publisher,
Function<Tuple2<O,T2>,V> zipper)
|
Modifier and Type | Method and Description |
---|---|
static <TUPLE extends Tuple,V> |
ZipAction.joinZipper() |
Constructor and Description |
---|
CombineLatestAction(Dispatcher dispatcher,
Function<TUPLE,? extends V> accumulator,
List<? extends org.reactivestreams.Publisher<? extends O>> composables) |
ZipAction(Dispatcher dispatcher,
Function<TUPLE,? extends V> accumulator,
List<? extends org.reactivestreams.Publisher<? extends O>> composables) |
Constructor and Description |
---|
RepeatWhenAction(Dispatcher dispatcher,
Function<? super Stream<? extends Long>,? extends org.reactivestreams.Publisher<?>> predicate,
org.reactivestreams.Publisher<? extends T> rootPublisher) |
ThrottleRequestWhenAction(Dispatcher dispatcher,
Function<? super Stream<? extends Long>,? extends org.reactivestreams.Publisher<? extends Long>> predicate) |
Constructor and Description |
---|
ErrorReturnAction(Class<E> selector,
Function<? super E,? extends T> function) |
RetryWhenAction(Dispatcher dispatcher,
Function<? super Stream<? extends Throwable>,? extends org.reactivestreams.Publisher<?>> predicate,
org.reactivestreams.Publisher<? extends T> rootPublisher) |
Constructor and Description |
---|
DistinctAction(Function<? super T,? extends V> keySelector) |
DistinctUntilChangedAction(Function<? super T,? extends V> keySelector) |
Constructor and Description |
---|
AdaptiveConsumerAction(Dispatcher dispatcher,
long initCapacity,
Consumer<? super T> consumer,
Function<Stream<Long>,? extends org.reactivestreams.Publisher<? extends Long>> requestMapper) |
Constructor and Description |
---|
GroupByAction(Environment environment,
Function<? super T,? extends K> fn,
Dispatcher dispatcher) |
MapAction(Function<? super T,? extends V> fn) |
Modifier and Type | Method and Description |
---|---|
<I,O> Function<I,O> |
BarrierStream.wrap(Function<I,O> fn) |
Modifier and Type | Method and Description |
---|---|
<I,O> Function<I,O> |
BarrierStream.wrap(Function<I,O> fn) |
Copyright © 2016. All rights reserved.