Package | Description |
---|---|
reactor | |
reactor.bus |
Hold the required abstraction to enable Event Driven Programming with Reactor.
|
reactor.bus.spec |
Specs help create
Reactors by providing a fluent API to specify
common options. |
reactor.core.dispatch |
Dispatchers provide a way for work to be done in another thread,
but unlike a standard thread pool, do so with extreme efficiency. |
reactor.core.processor |
This package offers a suite of asynchronous
Processor with backpressure support. |
reactor.core.reactivestreams | |
reactor.core.support | |
reactor.groovy.config | |
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.http |
Components for writing HTTP-based clients and servers using Reactor abstractions.
|
reactor.io.net.impl.netty |
Implementations of the various TCP abstractions based on Netty.
|
reactor.io.net.impl.netty.http | |
reactor.io.net.impl.netty.tcp | |
reactor.io.net.impl.netty.udp | |
reactor.io.net.impl.zmq | |
reactor.io.net.impl.zmq.tcp | |
reactor.io.net.tcp |
Components for writing TCP-based clients and servers using Reactor abstractions.
|
reactor.io.net.udp | |
reactor.rx |
Streams are reactive components derived from Reactive Extensions and implementing Reactive Streams specification.
|
reactor.rx.action.aggregation | |
reactor.rx.action.combination | |
reactor.rx.action.control | |
reactor.rx.action.error | |
reactor.rx.action.filter | |
reactor.rx.action.support | |
reactor.rx.action.terminal | |
reactor.rx.action.transformation | |
reactor.rx.broadcast |
Broadcasters are akin to Reactive Extensions Subject.
|
reactor.rx.stream |
Modifier and Type | Method and Description |
---|---|
static Dispatcher |
Environment.cachedDispatcher()
Obtain a cached dispatcher out of
this#PROCESSORS maximum pooled. |
static Dispatcher |
Environment.dispatcher(String key)
Obtain a registred dispatcher.
|
static Dispatcher |
Environment.dispatcher(String key,
Dispatcher dispatcher)
Register a dispatcher into the context environment.
|
Dispatcher |
Environment.getCachedDispatcher()
Returns a default cached dispatcher for this environment.
|
Dispatcher |
Environment.getDefaultDispatcher()
Returns the default dispatcher for this environment.
|
Dispatcher |
Environment.getDispatcher(String name)
Returns the dispatcher with the given
name . |
static Dispatcher |
Environment.newDispatcher()
Register a dispatcher into the context environment.
|
static Dispatcher |
Environment.newDispatcher(int backlog)
Register a dispatcher into the context environment.
|
static Dispatcher |
Environment.newDispatcher(int backlog,
int consumers)
Register a dispatcher into the context environment.
|
static Dispatcher |
Environment.newDispatcher(int backlog,
int consumers,
DispatcherType dispatcherType)
Register a dispatcher into the context environment.
|
static Dispatcher |
Environment.newDispatcher(String key,
int backlog)
Register a dispatcher into the context environment.
|
static Dispatcher |
Environment.newDispatcher(String key,
int backlog,
int consumers)
Register a dispatcher into the context environment.
|
static Dispatcher |
Environment.newDispatcher(String key,
int backlog,
int consumers,
DispatcherType dispatcherType)
Register a dispatcher into the context environment.
|
static Dispatcher |
Environment.newDispatcherLike(String key)
Register a dispatcher into the context environment.
|
static Dispatcher |
Environment.newDispatcherLike(String key,
String newKey)
Register a dispatcher into the context environment.
|
static Dispatcher |
Environment.sharedDispatcher()
Obtain the default dispatcher from the current environment.
|
static Dispatcher |
Environment.workDispatcher()
Obtain a multi threaded dispatcher useful for scaling up slow processing.
|
Modifier and Type | Method and Description |
---|---|
Iterator<Map.Entry<String,Dispatcher>> |
Environment.iterator() |
Modifier and Type | Method and Description |
---|---|
static Dispatcher |
Environment.dispatcher(String key,
Dispatcher dispatcher)
Register a dispatcher into the context environment.
|
Environment |
Environment.setDispatcher(String name,
Dispatcher dispatcher)
Adds the
dispatcher to the environment, storing it using the given name . |
Constructor and Description |
---|
Environment(Map<String,Dispatcher> dispatchers,
ConfigurationReader configurationReader)
Creates a new Environment that will contain the given
dispatchers , will use the given configurationReader to obtain additional configuration. |
Modifier and Type | Method and Description |
---|---|
Dispatcher |
EventBus.getDispatcher()
Get the
Dispatcher currently in use. |
Modifier and Type | Method and Description |
---|---|
static EventBus |
EventBus.create(Dispatcher dispatcher)
Create a new
EventBus using the given Dispatcher . |
static EventBus |
EventBus.create(Environment env,
Dispatcher dispatcher)
|
Constructor and Description |
---|
EventBus(Dispatcher dispatcher)
Create a new Reactor that uses the given
Dispatcher . |
EventBus(Dispatcher dispatcher,
Router router)
Create a new Reactor that uses the given
Dispatcher . |
EventBus(Dispatcher dispatcher,
Router router,
Consumer<Throwable> dispatchErrorHandler,
Consumer<Throwable> uncaughtErrorHandler) |
EventBus(Registry<Object,Consumer<? extends Event<?>>> consumerRegistry,
Dispatcher dispatcher,
Router router,
Consumer<Throwable> dispatchErrorHandler,
Consumer<Throwable> uncaughtErrorHandler)
Create a new Reactor that uses the given
dispatacher and eventRouter . |
Modifier and Type | Method and Description |
---|---|
protected abstract TARGET |
DispatcherComponentSpec.configure(Dispatcher dispatcher,
Environment environment) |
protected TARGET |
EventRoutingComponentSpec.configure(Dispatcher dispatcher,
Environment environment) |
SPEC |
DispatcherComponentSpec.dispatcher(Dispatcher dispatcher)
Configures the component to use the given
dispatcher |
Modifier and Type | Class and Description |
---|---|
class |
AbstractLifecycleDispatcher
A
Dispatcher that has a lifecycle. |
class |
MpscDispatcher
Implementation of a
Dispatcher that uses a MpscLinkedQueue to
queue tasks to execute. |
class |
MultiThreadDispatcher
Base implementation for multi-threaded dispatchers
|
class |
RingBufferDispatcher
Implementation of a
Dispatcher that uses a RingBuffer to queue tasks to execute. |
class |
SingleThreadDispatcher
Base Implementation for single-threaded Dispatchers.
|
class |
SynchronousDispatcher
A
Dispatcher implementation that dispatches events using the calling thread. |
class |
TailRecurseDispatcher
A
Dispatcher implementation that trampolines events using the calling thread and. |
class |
ThreadPoolExecutorDispatcher
A
Dispatcher that uses a ThreadPoolExecutor with an unbounded queue to dispatch events. |
class |
TraceableDelegatingDispatcher
An implementation of
Dispatcher that traces activity through it. |
class |
WorkQueueDispatcher
Implementation of a
Dispatcher that uses a multi-threaded, multi-producer RingBuffer to queue tasks
to execute. |
Constructor and Description |
---|
TraceableDelegatingDispatcher(Dispatcher delegate) |
Modifier and Type | Method and Description |
---|---|
boolean |
ReactorProcessor.isReactivePull(Dispatcher dispatcher,
long producerCapacity) |
Modifier and Type | Method and Description |
---|---|
boolean |
SubscriberBarrier.isReactivePull(Dispatcher dispatcher,
long producerCapacity) |
boolean |
SerializedSubscriber.isReactivePull(Dispatcher dispatcher,
long producerCapacity) |
Modifier and Type | Method and Description |
---|---|
boolean |
NonBlocking.isReactivePull(Dispatcher dispatcher,
long producerCapacity)
Get the assigned
Dispatcher . |
Modifier and Type | Method and Description |
---|---|
Dispatcher |
GroovyEnvironment.dispatcher(String dispatcher) |
Dispatcher |
EnvironmentBuilder.dispatcher(String name,
Dispatcher d) |
Dispatcher |
GroovyEnvironment.dispatcher(String dispatcherName,
Dispatcher dispatcher) |
Dispatcher |
ReactorBuilder.getDispatcher() |
Modifier and Type | Method and Description |
---|---|
Dispatcher |
EnvironmentBuilder.dispatcher(String name,
Dispatcher d) |
Dispatcher |
GroovyEnvironment.dispatcher(String dispatcherName,
Dispatcher dispatcher) |
void |
ReactorBuilder.setDispatcher(Dispatcher value) |
Modifier and Type | Method and Description |
---|---|
Dispatcher |
ReactorPeer.getDefaultDispatcher() |
Dispatcher |
ChannelStream.getDispatcher() |
Modifier and Type | Method and Description |
---|---|
protected TcpClient<IN,OUT> |
Spec.TcpClientSpec.configure(Dispatcher dispatcher,
Environment environment) |
protected TcpServer<IN,OUT> |
Spec.TcpServerSpec.configure(Dispatcher dispatcher,
Environment env) |
protected DatagramServer<IN,OUT> |
Spec.DatagramServerSpec.configure(Dispatcher dispatcher,
Environment environment) |
protected HttpServer<IN,OUT> |
Spec.HttpServerSpec.configure(Dispatcher dispatcher,
Environment env) |
protected HttpClient<IN,OUT> |
Spec.HttpClientSpec.configure(Dispatcher dispatcher,
Environment environment) |
Constructor and Description |
---|
ChannelStream(Environment env,
Codec<Buffer,IN,OUT> codec,
long prefetch,
Dispatcher eventsDispatcher) |
ReactorClient(Environment defaultEnv,
Dispatcher defaultDispatcher,
Codec<Buffer,IN,OUT> codec,
long prefetch) |
ReactorPeer(Environment defaultEnv,
Dispatcher defaultDispatcher,
Codec<Buffer,IN,OUT> codec) |
ReactorPeer(Environment defaultEnv,
Dispatcher defaultDispatcher,
Codec<Buffer,IN,OUT> codec,
long prefetch) |
Constructor and Description |
---|
HttpChannel(Environment env,
long prefetch,
Dispatcher eventsDispatcher) |
HttpClient(Environment env,
Dispatcher dispatcher,
Codec<Buffer,IN,OUT> codec,
ClientSocketOptions options) |
HttpServer(Environment env,
Dispatcher dispatcher,
Codec<Buffer,IN,OUT> codec) |
Constructor and Description |
---|
NettyChannelStream(Environment env,
Codec<Buffer,IN,OUT> codec,
long prefetch,
Dispatcher eventsDispatcher,
io.netty.channel.Channel ioChannel) |
Constructor and Description |
---|
NettyHttpClient(Environment env,
Dispatcher dispatcher,
Supplier<InetSocketAddress> connectAddress,
ClientSocketOptions options,
SslOptions sslOptions,
Codec<Buffer,IN,OUT> codec)
Creates a new NettyTcpClient that will use the given
env for configuration and the given reactor to
send events. |
NettyHttpServer(Environment env,
Dispatcher dispatcher,
InetSocketAddress listenAddress,
ServerSocketOptions options,
SslOptions sslOptions,
Codec<Buffer,IN,OUT> codec) |
Constructor and Description |
---|
NettyTcpClient(Environment env,
Dispatcher dispatcher,
Supplier<InetSocketAddress> hostSupplier,
ClientSocketOptions options,
SslOptions sslOptions,
Codec<Buffer,IN,OUT> codec)
Creates a new NettyTcpClient that will use the given
env for configuration and the given reactor to
send events. |
NettyTcpServer(Environment env,
Dispatcher dispatcher,
InetSocketAddress listenAddress,
ServerSocketOptions options,
SslOptions sslOptions,
Codec<Buffer,IN,OUT> codec) |
Constructor and Description |
---|
NettyDatagramServer(Environment env,
Dispatcher dispatcher,
InetSocketAddress listenAddress,
NetworkInterface multicastInterface,
ServerSocketOptions options,
Codec<Buffer,IN,OUT> codec) |
Constructor and Description |
---|
ZeroMQChannelStream(Environment env,
long prefetch,
Dispatcher eventsDispatcher,
InetSocketAddress remoteAddress,
Codec<Buffer,IN,OUT> codec) |
Constructor and Description |
---|
ZeroMQ(Environment env,
Dispatcher dispatcher) |
ZeroMQTcpClient(Environment env,
Dispatcher eventsDispatcher,
Supplier<InetSocketAddress> connectAddress,
ClientSocketOptions options,
SslOptions sslOptions,
Codec<Buffer,IN,OUT> codec) |
ZeroMQTcpServer(Environment env,
Dispatcher eventsDispatcher,
InetSocketAddress listenAddress,
ServerSocketOptions options,
SslOptions sslOptions,
Codec<Buffer,IN,OUT> codec) |
Constructor and Description |
---|
TcpClient(Environment env,
Dispatcher dispatcher,
Supplier<InetSocketAddress> connectAddress,
ClientSocketOptions options,
SslOptions sslOptions,
Codec<Buffer,IN,OUT> codec) |
TcpServer(Environment env,
Dispatcher dispatcher,
InetSocketAddress listenAddress,
ServerSocketOptions options,
SslOptions sslOptions,
Codec<Buffer,IN,OUT> codec) |
Constructor and Description |
---|
DatagramServer(Environment env,
Dispatcher dispatcher,
InetSocketAddress listenAddress,
NetworkInterface multicastInterface,
ServerSocketOptions options,
Codec<Buffer,IN,OUT> codec) |
Modifier and Type | Method and Description |
---|---|
Dispatcher |
Stream.getDispatcher()
Get the dispatcher used to execute signals on this Stream instance.
|
Modifier and Type | Method and Description |
---|---|
Control |
Stream.adaptiveConsumeOn(Dispatcher dispatcher,
Consumer<? super O> consumer,
Function<Stream<Long>,? extends org.reactivestreams.Publisher<? extends Long>> requestMapper)
|
Control |
Stream.batchConsumeOn(Dispatcher dispatcher,
Consumer<? super O> consumer,
Function<Long,? extends Long> requestMapper)
|
Stream<O> |
Stream.broadcastOn(Dispatcher dispatcher)
Subscribe a new
Broadcaster and return it for future subscribers interactions. |
Control |
Stream.consumeOn(Dispatcher dispatcher,
Consumer<? super O> consumer)
|
Control |
Stream.consumeOn(Dispatcher dispatcher,
Consumer<? super O> consumer,
Consumer<? super Throwable> errorConsumer)
|
Control |
Stream.consumeOn(Dispatcher dispatcher,
Consumer<? super O> consumer,
Consumer<? super Throwable> errorConsumer,
Consumer<Void> completeConsumer)
|
Stream<O> |
Stream.dispatchOn(Dispatcher dispatcher)
Assign a new Dispatcher to the returned Stream.
|
Stream<O> |
Stream.dispatchOn(Environment environment,
Dispatcher dispatcher)
Assign the a new Dispatcher and an Environment to the returned Stream.
|
static <T> Promise<T> |
Promises.error(Environment env,
Dispatcher dispatcher,
Throwable error)
|
boolean |
Stream.isReactivePull(Dispatcher dispatcher,
long producerCapacity) |
boolean |
Promise.isReactivePull(Dispatcher dispatcher,
long producerCapacity) |
static <T> Promise<T> |
Promises.ready(Environment env,
Dispatcher dispatcher)
Create a
Promise . |
Stream<O> |
Stream.subscribeOn(Dispatcher currentDispatcher)
Assign a new Dispatcher to handle upstream request to the returned Stream.
|
void |
Stream.subscribeOn(Dispatcher currentDispatcher,
org.reactivestreams.Subscriber<? super O> sub)
Assign a new Dispatcher to handle upstream request to the returned Stream.
|
static <T> Promise<T> |
Promises.success(Environment env,
Dispatcher dispatcher,
T value)
|
static <T> Action<org.reactivestreams.Publisher<? extends T>,T> |
Streams.switchOnNext(Dispatcher dispatcher)
Build an Action whose data are emitted by the most recent
Action.onNext(Object) signaled
publisher. |
static <T> Stream<T> |
Streams.switchOnNext(org.reactivestreams.Publisher<? extends org.reactivestreams.Publisher<? extends T>> mergedPublishers,
Dispatcher dispatcher)
Build a Stream whose data are emitted by the most recent passed publisher.
|
static <T> Promise<T> |
Promises.task(Environment env,
Dispatcher dispatcher,
Supplier<T> supplier)
|
Constructor and Description |
---|
Promise(Dispatcher dispatcher,
Environment env)
Creates a new unfulfilled promise.
|
Promise(O value,
Dispatcher dispatcher,
Environment env)
Creates a new promise that has been fulfilled with the given
value . |
Promise(Throwable error,
Dispatcher dispatcher,
Environment env)
Creates a new promise that has failed with the given
error . |
Modifier and Type | Field and Description |
---|---|
protected Dispatcher |
BatchAction.dispatcher |
Modifier and Type | Method and Description |
---|---|
Dispatcher |
BatchAction.getDispatcher() |
Dispatcher |
WindowShiftWhenAction.getDispatcher() |
Dispatcher |
WindowWhenAction.getDispatcher() |
Dispatcher |
WindowShiftAction.getDispatcher() |
Modifier and Type | Method and Description |
---|---|
boolean |
BatchAction.isReactivePull(Dispatcher dispatcher,
long producerCapacity) |
Constructor and Description |
---|
BatchAction(Dispatcher dispatcher,
int batchSize,
boolean next,
boolean first,
boolean flush) |
BatchAction(Dispatcher dispatcher,
int batchSize,
boolean next,
boolean first,
boolean flush,
long timespan,
TimeUnit unit,
Timer timer) |
BufferAction(Dispatcher dispatcher,
int batchsize) |
BufferAction(Dispatcher dispatcher,
int maxSize,
long timespan,
TimeUnit unit,
Timer timer) |
BufferShiftAction(Dispatcher dispatcher,
int size,
int skip) |
BufferShiftAction(Dispatcher dispatcher,
int size,
int skip,
long timeshift,
long timespan,
TimeUnit unit,
Timer timer) |
SampleAction(Dispatcher dispatcher,
boolean first,
int maxSize,
long timespan,
TimeUnit unit,
Timer timer) |
SampleAction(Dispatcher dispatcher,
int maxSize) |
SampleAction(Dispatcher dispatcher,
int maxSize,
boolean first) |
SortAction(Dispatcher dispatcher,
int batchsize,
Comparator<? super T> comparator) |
WindowAction(Environment environment,
Dispatcher dispatcher,
int backlog) |
WindowAction(Environment environment,
Dispatcher dispatcher,
int backlog,
long timespan,
TimeUnit unit,
Timer timer) |
WindowShiftAction(Environment environment,
Dispatcher dispatcher,
int size,
int skip) |
WindowShiftAction(Environment environment,
Dispatcher dispatcher,
int size,
int skip,
long timespan,
long timeshift,
TimeUnit unit,
Timer timer) |
WindowShiftWhenAction(Environment environment,
Dispatcher dispatcher,
org.reactivestreams.Publisher<?> bucketOpenings,
Supplier<? extends org.reactivestreams.Publisher<?>> boundarySupplier) |
WindowWhenAction(Environment environment,
Dispatcher dispatcher,
Supplier<? extends org.reactivestreams.Publisher<?>> boundarySupplier) |
Modifier and Type | Field and Description |
---|---|
protected Dispatcher |
FanInAction.dispatcher |
Modifier and Type | Method and Description |
---|---|
Dispatcher |
SwitchAction.getDispatcher() |
Dispatcher |
FanInAction.getDispatcher() |
Modifier and Type | Method and Description |
---|---|
boolean |
ZipAction.InnerSubscriber.isReactivePull(Dispatcher dispatcher,
long producerCapacity) |
boolean |
SwitchAction.SwitchSubscriber.isReactivePull(Dispatcher dispatcher,
long producerCapacity) |
boolean |
FanInAction.InnerSubscriber.isReactivePull(Dispatcher dispatcher,
long producerCapacity) |
boolean |
CombineLatestAction.InnerSubscriber.isReactivePull(Dispatcher dispatcher,
long producerCapacity) |
boolean |
MergeAction.InnerSubscriber.isReactivePull(Dispatcher dispatcher,
long producerCapacity) |
Constructor and Description |
---|
CombineLatestAction(Dispatcher dispatcher,
Function<TUPLE,? extends V> accumulator,
List<? extends org.reactivestreams.Publisher<? extends O>> composables) |
FanInAction(Dispatcher dispatcher) |
FanInAction(Dispatcher dispatcher,
List<? extends org.reactivestreams.Publisher<? extends I>> publishers) |
MergeAction(Dispatcher dispatcher) |
MergeAction(Dispatcher dispatcher,
List<? extends org.reactivestreams.Publisher<? extends O>> publishers) |
SwitchAction(Dispatcher dispatcher) |
ZipAction(Dispatcher dispatcher,
Function<TUPLE,? extends V> accumulator,
List<? extends org.reactivestreams.Publisher<? extends O>> composables) |
Modifier and Type | Method and Description |
---|---|
Dispatcher |
RepeatWhenAction.getDispatcher() |
Dispatcher |
RepeatAction.getDispatcher() |
Dispatcher |
DispatcherAction.getDispatcher() |
Modifier and Type | Method and Description |
---|---|
boolean |
DispatcherAction.isReactivePull(Dispatcher dispatcher,
long producerCapacity) |
boolean |
FlowControlAction.isReactivePull(Dispatcher dispatcher,
long producerCapacity) |
boolean |
ThrottleRequestWhenAction.isReactivePull(Dispatcher dispatcher,
long producerCapacity) |
boolean |
ThrottleRequestAction.isReactivePull(Dispatcher dispatcher,
long producerCapacity) |
Constructor and Description |
---|
DispatcherAction(Dispatcher dispatcher,
Dispatcher requestDispatcher) |
RepeatAction(Dispatcher dispatcher,
int numRetries,
org.reactivestreams.Publisher<? extends T> parentStream) |
RepeatWhenAction(Dispatcher dispatcher,
Function<? super Stream<? extends Long>,? extends org.reactivestreams.Publisher<?>> predicate,
org.reactivestreams.Publisher<? extends T> rootPublisher) |
ThrottleRequestAction(Dispatcher dispatcher,
Timer timer,
long period) |
ThrottleRequestWhenAction(Dispatcher dispatcher,
Function<? super Stream<? extends Long>,? extends org.reactivestreams.Publisher<? extends Long>> predicate) |
Modifier and Type | Method and Description |
---|---|
Dispatcher |
RetryWhenAction.getDispatcher() |
Dispatcher |
RetryAction.getDispatcher() |
Constructor and Description |
---|
RetryAction(Dispatcher dispatcher,
int numRetries,
Predicate<Throwable> predicate,
org.reactivestreams.Publisher<? extends T> parentStream) |
RetryWhenAction(Dispatcher dispatcher,
Function<? super Stream<? extends Throwable>,? extends org.reactivestreams.Publisher<?>> predicate,
org.reactivestreams.Publisher<? extends T> rootPublisher) |
TimeoutAction(Dispatcher dispatcher,
org.reactivestreams.Publisher<? extends T> fallback,
Timer timer,
long timeout) |
Constructor and Description |
---|
TakeUntilTimeout(Dispatcher dispatcher,
long time,
TimeUnit unit,
Timer timer) |
Modifier and Type | Method and Description |
---|---|
boolean |
DefaultSubscriber.isReactivePull(Dispatcher dispatcher,
long producerCapacity) |
Modifier and Type | Method and Description |
---|---|
Dispatcher |
AdaptiveConsumerAction.getDispatcher() |
Dispatcher |
ConsumerAction.getDispatcher() |
Modifier and Type | Method and Description |
---|---|
boolean |
AdaptiveConsumerAction.isReactivePull(Dispatcher dispatcher,
long producerCapacity) |
boolean |
ConsumerAction.isReactivePull(Dispatcher dispatcher,
long producerCapacity) |
Constructor and Description |
---|
AdaptiveConsumerAction(Dispatcher dispatcher,
long initCapacity,
Consumer<? super T> consumer,
Function<Stream<Long>,? extends org.reactivestreams.Publisher<? extends Long>> requestMapper) |
ConsumerAction(long capacity,
Dispatcher dispatcher,
Consumer<? super T> consumer,
Consumer<? super Throwable> errorConsumer,
Consumer<Void> completeConsumer) |
Modifier and Type | Method and Description |
---|---|
Dispatcher |
GroupByAction.getDispatcher() |
Constructor and Description |
---|
GroupByAction(Environment environment,
Function<? super T,? extends K> fn,
Dispatcher dispatcher) |
Modifier and Type | Field and Description |
---|---|
protected Dispatcher |
Broadcaster.dispatcher |
Modifier and Type | Method and Description |
---|---|
Dispatcher |
Broadcaster.getDispatcher() |
Modifier and Type | Method and Description |
---|---|
static <T> Broadcaster<T> |
BehaviorBroadcaster.create(Dispatcher dispatcher)
Build a Broadcaster, first broadcasting the most recent signal then ready to broadcast values with
Action.onNext(Object) ,
Broadcaster.onError(Throwable) , Broadcaster.onComplete() . |
static <T> Broadcaster<T> |
Broadcaster.create(Dispatcher dispatcher)
Build a Broadcaster, ready to broadcast values with
Action.onNext(Object) ,
Broadcaster.onError(Throwable) , Broadcaster.onComplete() . |
static <T> Broadcaster<T> |
BehaviorBroadcaster.create(Environment env,
Dispatcher dispatcher)
Build a Broadcaster, first broadcasting the most recent signal then
ready to broadcast values with
(Object) ,
Broadcaster.onError(Throwable) , Broadcaster.onComplete() . |
static <T> Broadcaster<T> |
Broadcaster.create(Environment env,
Dispatcher dispatcher)
Build a Broadcaster, ready to broadcast values with
(Object) ,
Broadcaster.onError(Throwable) , Broadcaster.onComplete() . |
static <T> Broadcaster<T> |
BehaviorBroadcaster.first(T value,
Dispatcher dispatcher)
Build a Broadcaster, first broadcasting the most recent signal then starting with the passed value,
then ready to broadcast values with
Action.onNext(Object) ,
Broadcaster.onError(Throwable) , Broadcaster.onComplete() . |
static <T> Broadcaster<T> |
BehaviorBroadcaster.first(T value,
Environment env,
Dispatcher dispatcher)
Build a Broadcaster, first broadcasting the most recent signal then starting with the passed value,
then ready to broadcast values with
(Object) ,
Broadcaster.onError(Throwable) , Broadcaster.onComplete() . |
Constructor and Description |
---|
Broadcaster(Environment environment,
Dispatcher dispatcher,
long capacity)
INTERNAL
|
Modifier and Type | Method and Description |
---|---|
Dispatcher |
LiftStream.getDispatcher() |
Constructor and Description |
---|
BarrierStream(Dispatcher dispatcher) |
BarrierStream(Environment env,
Dispatcher dispatcher) |
SupplierStream(Dispatcher dispatcher,
Supplier<? extends T> supplier) |
Copyright © 2016. All rights reserved.