Skip navigation links
Reactor JavaDocs
$ A B C D E F G H I J K L M N O P Q R S T U V W X Y Z 

$

$() - Static method in class reactor.bus.selector.Selectors
A short-hand alias for Selectors.anonymous().
$(T) - Static method in class reactor.bus.selector.Selectors
A short-hand alias for Selectors.object(T).
$(String, Object...) - Static method in class reactor.bus.selector.Selectors
Creates a Selector based on the given string format and arguments.

A

AbstractLifecycleDispatcher - Class in reactor.core.dispatch
A Dispatcher that has a lifecycle.
AbstractLifecycleDispatcher() - Constructor for class reactor.core.dispatch.AbstractLifecycleDispatcher
 
AbstractLifecycleDispatcher.Task - Class in reactor.core.dispatch
 
AbstractReference<T extends Recyclable> - Class in reactor.alloc
An abstract Reference implementation that does reference counting.
AbstractReference(T) - Constructor for class reactor.alloc.AbstractReference
 
accept(Event<?>) - Method in class reactor.bus.EventBus
 
accept(E) - Method in class reactor.bus.EventBus.ReplyToConsumer
 
accept(Event<T>) - Method in class reactor.bus.support.EventConsumer
 
accept(T) - Method in class reactor.bus.support.NotifyConsumer
 
accept(IN) - Method in class reactor.core.processor.ReactorProcessor
 
accept(LEFT, RIGHT) - Method in interface reactor.fn.BiConsumer
 
accept(T) - Method in interface reactor.fn.Consumer
Execute the logic of the action, accepting the given parameter.
accept(T) - Method in class reactor.fn.support.Tap
 
accept(T) - Method in class reactor.groovy.support.ClosureConsumer
 
accept(Event<T>) - Method in class reactor.groovy.support.ClosureEventConsumer
 
accept(Tuple) - Method in class reactor.groovy.support.ClosureTupleConsumer
 
ACCEPT - Static variable in interface reactor.io.net.http.model.HttpHeaders
The HTTP Accept header field name.
accept(I) - Method in class reactor.rx.action.Action
 
accept(Long) - Method in class reactor.rx.action.combination.FanInAction.InnerSubscriber
 
accept(Subscriber<? super T>) - Method in class reactor.rx.action.Signal
 
accept(O) - Method in class reactor.rx.Promise
 
accept(Stream<?>) - Method in class reactor.rx.StreamUtils.StreamVisitor
 
accept(Long) - Method in class reactor.rx.subscription.PushSubscription
 
ACCEPT_CHARSET - Static variable in interface reactor.io.net.http.model.HttpHeaders
The HTTP Accept-Charset header field name.
ACCEPT_ENCODING - Static variable in interface reactor.io.net.http.model.HttpHeaders
The HTTP Accept-Encoding header field name.
ACCEPT_LANGUAGE - Static variable in interface reactor.io.net.http.model.HttpHeaders
The HTTP Accept-Language header field name.
ACCEPT_RANGES - Static variable in interface reactor.io.net.http.model.ResponseHeaders
The HTTP Accept-Ranges header field name.
ACCEPTED - Static variable in class reactor.io.net.http.model.Status
202 Accepted
Action<I,O> - Class in reactor.rx.action
An Action is a reactive component to subscribe to a Publisher and in particular to a Stream.
Action() - Constructor for class reactor.rx.action.Action
 
Action(long) - Constructor for class reactor.rx.action.Action
 
adaptiveConsume(Consumer<? super O>, Function<Stream<Long>, ? extends Publisher<? extends Long>>) - Method in class reactor.rx.Stream
Attach a Consumer to this Stream that will consume any values accepted by this Stream.
adaptiveConsumeOn(Dispatcher, Consumer<? super O>, Function<Stream<Long>, ? extends Publisher<? extends Long>>) - Method in class reactor.rx.Stream
Attach a Consumer to this Stream that will consume any values accepted by this Stream.
AdaptiveConsumerAction<T> - Class in reactor.rx.action.terminal
 
AdaptiveConsumerAction(Dispatcher, long, Consumer<? super T>, Function<Stream<Long>, ? extends Publisher<? extends Long>>) - Constructor for class reactor.rx.action.terminal.AdaptiveConsumerAction
 
add(E) - Method in class reactor.core.queue.internal.MpscLinkedQueue
 
add(String, String) - Method in interface reactor.io.net.http.model.WritableHeaders
 
add(String, Iterable<String>) - Method in interface reactor.io.net.http.model.WritableHeaders
 
add(String, String) - Method in class reactor.io.net.impl.netty.http.NettyHttpHeaders
 
add(String, Iterable<String>) - Method in class reactor.io.net.impl.netty.http.NettyHttpHeaders
 
add(String, String) - Method in class reactor.io.net.impl.netty.http.NettyHttpResponseHeaders
 
add(String, Iterable<String>) - Method in class reactor.io.net.impl.netty.http.NettyHttpResponseHeaders
 
add(PushSubscription<O>) - Method in class reactor.rx.subscription.FanOutSubscription
 
addAll(Collection<? extends E>) - Method in class reactor.core.queue.internal.MpscLinkedQueue
 
addAppender(Appender<ILoggingEvent>) - Method in class reactor.logback.AsyncAppender
 
addCachedDispatchers(String, DispatcherSupplier) - Method in class reactor.Environment
Adds the dispatcherFactory to the environment, storing it using the given name.
addCause(Throwable, Throwable) - Static method in class reactor.core.support.Exceptions
Adds a Throwable to a causality-chain of Throwables, as an additional cause (if it does not already appear in the chain among the causes).
addConsumersFrom(ReactorBuilder) - Method in class reactor.groovy.config.ReactorBuilder
 
addDateHeader(String, Date) - Method in interface reactor.io.net.http.model.WritableHeaders
 
addDateHeader(String, Date) - Method in class reactor.io.net.impl.netty.http.NettyHttpHeaders
 
addDateHeader(String, Date) - Method in class reactor.io.net.impl.netty.http.NettyHttpResponseHeaders
 
addDelimiterIfAny(Buffer) - Method in class reactor.io.codec.Codec
Add a trailing delimiter if defined
addFilter(Filter<ILoggingEvent>) - Method in class reactor.logback.AsyncAppender
 
addHeader(String, String) - Method in class reactor.io.net.http.HttpChannel
Accumulate a Request Header using the given name and value, appending ";" for each new value
addPublisher(Publisher<? extends I>) - Method in class reactor.rx.action.combination.FanInAction
 
addResponseHeader(String, String) - Method in class reactor.io.net.http.HttpChannel
Accumulate a response HTTP header for the given key name, appending ";" for each new value
address(InetSocketAddress) - Method in class reactor.io.net.Spec.IncrementalBackoffReconnect
Add an address to the pool of addresses.
address(String, int) - Method in class reactor.io.net.Spec.IncrementalBackoffReconnect
Add an address to the pool of addresses.
addSecureHandler(SocketChannel) - Method in class reactor.io.net.impl.netty.tcp.NettyTcpClient
 
addSubscription(PushSubscription<O>) - Method in class reactor.rx.action.Action
 
addValueAsLastCause(Throwable, Object) - Static method in class reactor.core.support.Exceptions
Adds the given item as the final cause of the given Throwable, wrapped in OnNextValue (which extends RuntimeException).
AFTER - Static variable in class reactor.io.net.http.model.Method
 
after() - Method in class reactor.rx.Promise
Only forward onError and onComplete signals into the returned stream.
after() - Method in class reactor.rx.Stream
Only forward onError and onComplete signals into the returned stream.
AfterAction<T> - Class in reactor.rx.action.passive
 
AfterAction() - Constructor for class reactor.rx.action.passive.AfterAction
 
AGE - Static variable in interface reactor.io.net.http.model.ResponseHeaders
The HTTP Age header field name.
AgileWaitingStrategy - Class in reactor.core.dispatch.wait
A pair of slow and fast wait strategies to dynamically adapt to a given application load
AgileWaitingStrategy() - Constructor for class reactor.core.dispatch.wait.AgileWaitingStrategy
 
AgileWaitingStrategy(WaitStrategy, WaitStrategy) - Constructor for class reactor.core.dispatch.wait.AgileWaitingStrategy
 
alive() - Method in class reactor.core.dispatch.AbstractLifecycleDispatcher
 
alive() - Method in class reactor.core.dispatch.SynchronousDispatcher
 
alive() - Method in class reactor.core.dispatch.TailRecurseDispatcher
 
alive() - Method in class reactor.core.dispatch.TraceableDelegatingDispatcher
 
alive() - Method in class reactor.core.processor.ExecutorPoweredProcessor
 
alive() - Static method in class reactor.Environment
Read if the context environment has been set
alive() - Method in interface reactor.fn.Resource
Determine whether this Resource can be used.
allocate() - Method in interface reactor.alloc.Allocator
Allocate an object from the internal pool.
allocate() - Method in class reactor.alloc.ReferenceCountingAllocator
 
allocate() - Method in class reactor.io.buffer.BufferAllocator
 
allocateBatch(int) - Method in interface reactor.alloc.Allocator
Allocate a batch of objects all at once.
allocateBatch(int) - Method in class reactor.alloc.ReferenceCountingAllocator
 
allocateBatch(int) - Method in class reactor.io.buffer.BufferAllocator
 
allocateRecursiveTask() - Method in class reactor.core.dispatch.AbstractLifecycleDispatcher
 
allocateRecursiveTask() - Method in class reactor.core.dispatch.MultiThreadDispatcher
 
allocateRecursiveTask() - Method in class reactor.core.dispatch.SingleThreadDispatcher
 
allocateTask() - Method in class reactor.core.dispatch.AbstractLifecycleDispatcher
 
allocateTask() - Method in class reactor.core.dispatch.MpscDispatcher
 
allocateTask() - Method in class reactor.core.dispatch.MultiThreadDispatcher
 
allocateTask() - Method in class reactor.core.dispatch.RingBufferDispatcher
 
allocateTask() - Method in class reactor.core.dispatch.SingleThreadDispatcher
 
allocateTask() - Method in class reactor.core.dispatch.WorkQueueDispatcher
 
Allocator<T extends Recyclable> - Interface in reactor.alloc
An Allocator is responsible for returning to the caller a Reference to a reusable object or to provide a newly-created object, depending on the underlying allocation strategy.
ALLOW - Static variable in interface reactor.io.net.http.model.ResponseHeaders
The HTTP Allow header field name.
always() - Static method in class reactor.fn.Predicates
Deprecated.
Returns a Predicate which always evaluates to true.
and(Predicate<? super T>...) - Static method in class reactor.fn.Predicates
Deprecated.
Returns a Predicate which evaluates to true only if all the provided predicates evaluate to true.
and(Stream<T>, Predicate<T>) - Static method in class reactor.groovy.ext.StreamExtensions
 
and(Promise<T>, Predicate<T>) - Static method in class reactor.groovy.ext.StreamExtensions
 
anonymous() - Static method in class reactor.bus.selector.Selectors
Creates an anonymous Selector.
AnonymousKey() - Constructor for class reactor.bus.selector.Selectors.AnonymousKey
 
any(Promise<T>...) - Static method in class reactor.rx.Promises
Pick the first result coming from any of the given promises and populate a new Promise.
any(List<? extends Promise<T>>) - Static method in class reactor.rx.Promises
Pick the first result coming from any of the given promises and populate a new Promise.
append(String) - Method in class reactor.io.buffer.Buffer
Append the given String to this Buffer.
append(short) - Method in class reactor.io.buffer.Buffer
Append the given short to this Buffer.
append(int) - Method in class reactor.io.buffer.Buffer
Append the given int to this Buffer.
append(long) - Method in class reactor.io.buffer.Buffer
Append the given long to this Buffer.
append(char) - Method in class reactor.io.buffer.Buffer
Append the given char to this Buffer.
append(ByteBuffer...) - Method in class reactor.io.buffer.Buffer
Append the given ByteBuffer to this Buffer.
append(Buffer...) - Method in class reactor.io.buffer.Buffer
Append the given Buffer to this Buffer.
append(byte) - Method in class reactor.io.buffer.Buffer
Append the given byte to this Buffer.
append(byte[]) - Method in class reactor.io.buffer.Buffer
Append the given byte[] to this Buffer.
append(byte[], int, int) - Method in class reactor.io.buffer.Buffer
Append the given byte[] to this Buffer, starting at the given index and continuing for the given length.
apply(LEFT, RIGHT) - Method in interface reactor.fn.BiFunction
 
apply(T) - Method in interface reactor.fn.Function
Execute the logic of the action, accepting the given parameter.
apply(Event<K>) - Method in class reactor.groovy.support.ClosureEventFunction
 
apply(K) - Method in class reactor.groovy.support.ClosureFunction
 
apply(Tuple2<T, V>) - Method in class reactor.groovy.support.ClosureReduce
 
apply(byte[]) - Method in class reactor.io.codec.ByteArrayCodec
 
apply(OUT) - Method in class reactor.io.codec.compress.CompressionCodec
 
apply(OUT) - Method in class reactor.io.codec.DelimitedCodec
 
apply(Frame) - Method in class reactor.io.codec.FrameCodec
 
apply(T) - Method in class reactor.io.codec.JavaSerializationCodec
 
apply(OUT) - Method in class reactor.io.codec.json.JsonCodec
 
apply(OUT) - Method in class reactor.io.codec.LengthFieldCodec
 
apply(SRC) - Method in class reactor.io.codec.PassThroughCodec
 
apply(OUT) - Method in class reactor.io.codec.SerializationCodec
 
apply(String) - Method in class reactor.io.codec.StringCodec
 
apply(String) - Method in class reactor.io.codec.StringCodec.StringEncoder
 
apply(Void) - Method in class reactor.io.net.codec.syslog.SyslogCodec
 
approxCurrentTimeMillis() - Static method in class reactor.fn.timer.TimeUtils
 
asBytes() - Method in class reactor.io.buffer.Buffer
Return the contents of this buffer copied into a byte[].
asMap() - Method in class reactor.bus.Event.Headers
Get these headers as an unmodifiable Map.
Assert - Class in reactor.core.support
Assertion utility class that assists in validating arguments.
Assert() - Constructor for class reactor.core.support.Assert
 
assign(Environment) - Static method in class reactor.Environment
Assign an environment to the context in order to make it available statically in the application from the current classloader.
assignErrorJournal() - Method in class reactor.Environment
Assign a default error Consumer to listen for any call to this#routeError(Throwable).
assignErrorJournal(Consumer<? super Throwable>) - Method in class reactor.Environment
Assign the error Consumer to listen for any call to this#routeError(Throwable).
asString() - Method in class reactor.io.buffer.Buffer
Convert the contents of this buffer into a String using a UTF-8 CharsetDecoder.
AsyncAppender - Class in reactor.logback
A Logback Appender implementation that uses a Reactor RingBufferProcessor internally to queue events to a single-writer thread.
AsyncAppender() - Constructor for class reactor.logback.AsyncAppender
 
AUTHORIZATION - Static variable in interface reactor.io.net.http.model.HttpHeaders
The HTTP Authorization header field name.
autoCancel - Variable in class reactor.core.processor.ReactorProcessor
 
await() - Method in class reactor.rx.Promise
Block the calling thread, waiting for the completion of this Promise.
await(long, TimeUnit) - Method in class reactor.rx.Promise
Block the calling thread for the specified time, waiting for the completion of this Promise.
await(Publisher<?>) - Static method in class reactor.rx.Streams
Wait 30 Seconds until a terminal signal from the passed publisher has been emitted.
await(Publisher<?>, long) - Static method in class reactor.rx.Streams
Wait {code timeout} Seconds until a terminal signal from the passed publisher has been emitted.
await(Publisher<?>, long, TimeUnit) - Static method in class reactor.rx.Streams
Wait {code timeout} in unit until a terminal signal from the passed publisher has been emitted.
await(Publisher<?>, long, TimeUnit, boolean) - Static method in class reactor.rx.Streams
Wait {code timeout} in unit until a terminal signal from the passed publisher has been emitted.
awaitAndShutdown() - Method in class reactor.core.dispatch.AbstractLifecycleDispatcher
 
awaitAndShutdown(long, TimeUnit) - Method in class reactor.core.dispatch.MpscDispatcher
 
awaitAndShutdown(long, TimeUnit) - Method in class reactor.core.dispatch.RingBufferDispatcher
 
awaitAndShutdown() - Method in class reactor.core.dispatch.SynchronousDispatcher
 
awaitAndShutdown(long, TimeUnit) - Method in class reactor.core.dispatch.SynchronousDispatcher
 
awaitAndShutdown() - Method in class reactor.core.dispatch.TailRecurseDispatcher
 
awaitAndShutdown(long, TimeUnit) - Method in class reactor.core.dispatch.TailRecurseDispatcher
 
awaitAndShutdown(long, TimeUnit) - Method in class reactor.core.dispatch.ThreadPoolExecutorDispatcher
 
awaitAndShutdown() - Method in class reactor.core.dispatch.TraceableDelegatingDispatcher
 
awaitAndShutdown(long, TimeUnit) - Method in class reactor.core.dispatch.TraceableDelegatingDispatcher
 
awaitAndShutdown(long, TimeUnit) - Method in class reactor.core.dispatch.WorkQueueDispatcher
 
awaitAndShutdown() - Method in class reactor.core.processor.ExecutorPoweredProcessor
 
awaitAndShutdown(long, TimeUnit) - Method in class reactor.core.processor.ExecutorPoweredProcessor
 
awaitAndShutdown() - Method in interface reactor.fn.Resource
Block until all submitted tasks have completed, then do a normal Resource.shutdown().
awaitAndShutdown(long, TimeUnit) - Method in interface reactor.fn.Resource
Block until all submitted tasks have completed, then do a normal Resource.shutdown().
awaitSuccess() - Method in class reactor.rx.Promise
Block the calling thread, waiting for the completion of this Promise.
awaitSuccess(long, TimeUnit) - Method in class reactor.rx.Promise
Block the calling thread for the specified time, waiting for the completion of this Promise.
awaitTermination(long, TimeUnit) - Method in class reactor.core.processor.util.SingleUseExecutor
 

B

backlog - Variable in class reactor.core.dispatch.SingleThreadDispatcher
 
backlog() - Method in class reactor.io.net.config.ServerSocketOptions
Returns the configured pending connection backlog for the socket.
backlog(int) - Method in class reactor.io.net.config.ServerSocketOptions
Configures the size of the pending connection backlog for the socket.
backlogSize() - Method in class reactor.core.dispatch.MultiThreadDispatcher
 
backlogSize() - Method in class reactor.core.dispatch.SingleThreadDispatcher
 
backlogSize() - Method in class reactor.core.dispatch.SynchronousDispatcher
 
backlogSize() - Method in class reactor.core.dispatch.TailRecurseDispatcher
 
backlogSize() - Method in class reactor.core.dispatch.TraceableDelegatingDispatcher
 
backlogSize() - Method in interface reactor.core.Dispatcher
Request the capacity for the underlying shared state structure.
backoffReconnect() - Static method in class reactor.io.net.NetStreams
 
BAD_GATEWAY - Static variable in class reactor.io.net.http.model.Status
502 Bad Gateway
BAD_REQUEST - Static variable in class reactor.io.net.http.model.Status
400 Bad Request
barrier(Publisher<I>, BiConsumer<I, Subscriber<? super O>>) - Static method in class reactor.core.reactivestreams.PublisherFactory
Intercept a source Publisher onNext signal to eventually transform, forward or filter the data by calling or not the right operand Subscriber.
barrier(Publisher<I>, BiConsumer<I, Subscriber<? super O>>, BiConsumer<Throwable, Subscriber<? super O>>) - Static method in class reactor.core.reactivestreams.PublisherFactory
Intercept a source Publisher onNext signal to eventually transform, forward or filter the data by calling or not the right operand Subscriber.
barrier(Publisher<I>, BiConsumer<I, Subscriber<? super O>>, BiConsumer<Throwable, Subscriber<? super O>>, Consumer<Subscriber<? super O>>) - Static method in class reactor.core.reactivestreams.PublisherFactory
Intercept a source Publisher onNext signal to eventually transform, forward or filter the data by calling or not the right operand Subscriber.
BarrierStream - Class in reactor.rx.stream
A BarrierStream provides a type of Stream into which you can bind Consumers and Functions from arbitrary components.
BarrierStream() - Constructor for class reactor.rx.stream.BarrierStream
 
BarrierStream(Environment) - Constructor for class reactor.rx.stream.BarrierStream
 
BarrierStream(Dispatcher) - Constructor for class reactor.rx.stream.BarrierStream
 
BarrierStream(Environment, Dispatcher) - Constructor for class reactor.rx.stream.BarrierStream
 
basePath(String) - Method in class reactor.io.queue.spec.PersistentQueueSpec
 
BatchAction<T,V> - Class in reactor.rx.action.aggregation
 
BatchAction(Dispatcher, int, boolean, boolean, boolean) - Constructor for class reactor.rx.action.aggregation.BatchAction
 
BatchAction(Dispatcher, int, boolean, boolean, boolean, long, TimeUnit, Timer) - Constructor for class reactor.rx.action.aggregation.BatchAction
 
batchConsume(Consumer<? super O>, Function<Long, ? extends Long>) - Method in class reactor.rx.Stream
Attach a Consumer to this Stream that will consume any values accepted by this Stream.
batchConsumeOn(Dispatcher, Consumer<? super O>, Function<Long, ? extends Long>) - Method in class reactor.rx.Stream
Attach a Consumer to this Stream that will consume any values accepted by this Stream.
batchSize - Variable in class reactor.rx.action.aggregation.BatchAction
 
BatchSubscription<T> - Class in reactor.rx.subscription
A Subscription wrapper which request
BatchSubscription(Subscription, Subscriber<T>, int) - Constructor for class reactor.rx.subscription.BatchSubscription
 
BEFORE - Static variable in class reactor.io.net.http.model.Method
 
beforeAccept(SRC) - Method in class reactor.io.codec.PassThroughCodec
Override to intercept the source object before it is passed into the next Consumer or returned to the caller if a Consumer is not set.
beforeApply(SRC) - Method in class reactor.io.codec.PassThroughCodec
Override to intercept the source object before it is returned for output.
BehaviorBroadcaster<O> - Class in reactor.rx.broadcast
A Broadcaster is a subclass of Stream which exposes methods for publishing values into the pipeline.
BiConsumer<LEFT,RIGHT> - Interface in reactor.fn
Implementations of this class perform work on the given parameters pair.
BiFunction<LEFT,RIGHT,R> - Interface in reactor.fn
Implementations of this class perform work on the given parameters pair and return a result of an optionally different type.
bindChannel(ReactorChannelHandler<IN, OUT, ChannelStream<IN, OUT>>, Object) - Method in class reactor.io.net.impl.netty.http.NettyHttpClient
 
bindChannel(ReactorChannelHandler<IN, OUT, ChannelStream<IN, OUT>>, SocketChannel) - Method in class reactor.io.net.impl.netty.http.NettyHttpServer
 
bindChannel(ReactorChannelHandler<IN, OUT, ChannelStream<IN, OUT>>, SocketChannel) - Method in class reactor.io.net.impl.netty.tcp.NettyTcpClient
 
bindChannel(ReactorChannelHandler<IN, OUT, ChannelStream<IN, OUT>>, SocketChannel) - Method in class reactor.io.net.impl.netty.tcp.NettyTcpServer
 
bindChannel(ReactorChannelHandler<IN, OUT, ChannelStream<IN, OUT>>, Object) - Method in class reactor.io.net.impl.netty.udp.NettyDatagramServer
 
bindChannel() - Method in class reactor.io.net.impl.zmq.tcp.ZeroMQTcpClient
 
bindChannel() - Method in class reactor.io.net.impl.zmq.tcp.ZeroMQTcpServer
 
BiStreams - Class in reactor.rx
A Streams add-on to work with key/value pairs hydrated in Tuple2.
broadcast() - Method in class reactor.rx.Stream
Subscribe a new Broadcaster and return it for future subscribers interactions.
broadcastComplete() - Method in class reactor.rx.action.Action
Send a complete event to all the attached Subscriber ONLY IF the underlying state is READY.
Broadcaster<O> - Class in reactor.rx.broadcast
A Broadcaster is a subclass of Stream which exposes methods for publishing values into the pipeline.
Broadcaster(Environment, Dispatcher, long) - Constructor for class reactor.rx.broadcast.Broadcaster
INTERNAL
broadcastError(Throwable) - Method in class reactor.rx.action.Action
Send an error to all the attached Subscriber.
broadcastEventRouting() - Method in class reactor.bus.spec.EventRoutingComponentSpec
Configures the component's EventRouter to broadcast events to all matching consumers
broadcastNext(O) - Method in class reactor.rx.action.Action
Send an element of parameterized type {link O} to all the attached Subscriber.
broadcastOn(Dispatcher) - Method in class reactor.rx.Stream
Subscribe a new Broadcaster and return it for future subscribers interactions.
broadcastTo(E) - Method in class reactor.rx.Stream
Subscribe the passed subscriber, only creating once necessary upstream Subscriptions and returning itself.
broadcastTuple() - Method in class reactor.rx.action.combination.CombineLatestAction
 
broadcastTuple(boolean) - Method in class reactor.rx.action.combination.ZipAction
 
browse(Stream<O>) - Static method in class reactor.rx.StreamUtils
 
browse(Stream<O>, StreamUtils.DebugVisitor) - Static method in class reactor.rx.StreamUtils
 
Buffer - Class in reactor.io.buffer
A Buffer is a general-purpose IO utility class that wraps a ByteBuffer.
Buffer() - Constructor for class reactor.io.buffer.Buffer
Create an empty Buffer that is dynamic.
Buffer(int, boolean) - Constructor for class reactor.io.buffer.Buffer
Create an Buffer that has an internal ByteBuffer allocated to the given size and optional make this buffer fixed-length.
Buffer(Buffer) - Constructor for class reactor.io.buffer.Buffer
Copy constructor that creates a shallow copy of the given Buffer by calling ByteBuffer.duplicate() on the underlying ByteBuffer.
Buffer(ByteBuffer) - Constructor for class reactor.io.buffer.Buffer
Create a Buffer using the given ByteBuffer as the inital source.
buffer() - Method in class reactor.rx.Stream
Collect incoming values into a List that will be pushed into the returned Stream every time Stream.getCapacity() has been reached, or flush is triggered.
buffer(int) - Method in class reactor.rx.Stream
Collect incoming values into multiple List buckets that will be pushed into the returned Stream every time Stream.getCapacity() has been reached.
buffer(Publisher<?>, Supplier<? extends Publisher<?>>) - Method in class reactor.rx.Stream
Collect incoming values into a List that will be moved into the returned Stream every time the passed boundary publisher emits an item.
buffer(Supplier<? extends Publisher<?>>) - Method in class reactor.rx.Stream
Collect incoming values into a List that will be moved into the returned Stream every time the passed boundary publisher emits an item.
buffer(int, int) - Method in class reactor.rx.Stream
Collect incoming values into a List that will be pushed into the returned Stream every time maxSize has been reached by any of them.
buffer(long, TimeUnit) - Method in class reactor.rx.Stream
Collect incoming values into a List that will be pushed into the returned Stream every timespan.
buffer(long, TimeUnit, Timer) - Method in class reactor.rx.Stream
Collect incoming values into a List that will be pushed into the returned Stream every timespan.
buffer(long, long, TimeUnit) - Method in class reactor.rx.Stream
Collect incoming values into multiple List buckets created every timeshift that will be pushed into the returned Stream every timespan.
buffer(long, long, TimeUnit, Timer) - Method in class reactor.rx.Stream
Collect incoming values into multiple List buckets created every timeshift that will be pushed into the returned Stream every timespan.
buffer(int, long, TimeUnit) - Method in class reactor.rx.Stream
Collect incoming values into a List that will be pushed into the returned Stream every timespan OR maxSize items.
buffer(int, long, TimeUnit, Timer) - Method in class reactor.rx.Stream
Collect incoming values into a List that will be pushed into the returned Stream every timespan OR maxSize items
buffer - Variable in class reactor.rx.subscription.ReactiveSubscription
 
Buffer.View - Class in reactor.io.buffer
A View represents a segment of a buffer.
BufferAction<T> - Class in reactor.rx.action.aggregation
 
BufferAction(Dispatcher, int) - Constructor for class reactor.rx.action.aggregation.BufferAction
 
BufferAction(Dispatcher, int, long, TimeUnit, Timer) - Constructor for class reactor.rx.action.aggregation.BufferAction
 
BufferAllocator - Class in reactor.io.buffer
An Allocator implementation that allocates Buffers.
BufferAllocator() - Constructor for class reactor.io.buffer.BufferAllocator
Create a BufferAllocator of size=256, direct=false, and bufferSize=Buffer.SMALL_BUFFER_SIZE.
BufferAllocator(int, boolean, int) - Constructor for class reactor.io.buffer.BufferAllocator
Create a BufferAllocator.
BufferCodec<IN,OUT> - Class in reactor.io.codec
Implementations of a BufferCodec are codec manipulating Buffer sources
BufferCodec() - Constructor for class reactor.io.codec.BufferCodec
Create a new Codec set with a \0 delimiter to finish any Buffer encoded value or scan for delimited decoded Buffers.
BufferCodec(Byte) - Constructor for class reactor.io.codec.BufferCodec
A delimiter can be used to trail any decoded buffer or to finalize encoding from any incoming value
BufferShiftAction<T> - Class in reactor.rx.action.aggregation
 
BufferShiftAction(Dispatcher, int, int) - Constructor for class reactor.rx.action.aggregation.BufferShiftAction
 
BufferShiftAction(Dispatcher, int, int, long, long, TimeUnit, Timer) - Constructor for class reactor.rx.action.aggregation.BufferShiftAction
 
BufferShiftWhenAction<T> - Class in reactor.rx.action.aggregation
 
BufferShiftWhenAction(Publisher<?>, Supplier<? extends Publisher<?>>) - Constructor for class reactor.rx.action.aggregation.BufferShiftWhenAction
 
BufferWhenAction<T> - Class in reactor.rx.action.aggregation
 
BufferWhenAction(Supplier<? extends Publisher<?>>) - Constructor for class reactor.rx.action.aggregation.BufferWhenAction
 
build(Reader) - Static method in class reactor.groovy.config.GroovyEnvironment
 
build(File) - Static method in class reactor.groovy.config.GroovyEnvironment
 
build(String) - Static method in class reactor.groovy.config.GroovyEnvironment
 
Bus<T> - Interface in reactor.bus
Basic unit of event handling in Reactor.
BusExtensions - Class in reactor.groovy.ext
 
BusExtensions() - Constructor for class reactor.groovy.ext.BusExtensions
 
BusPublisher<T> - Class in reactor.bus.publisher
Emit signals whenever an Event arrives from the Selector topic from the Bus.
BusPublisher(Bus<T>, Selector) - Constructor for class reactor.bus.publisher.BusPublisher
 
BusySpinWait() - Constructor for class reactor.fn.timer.HashWheelTimer.BusySpinWait
 
BYTE_ARRAY_CODEC - Static variable in class reactor.io.codec.StandardCodecs
ByteArrayCodec - Class in reactor.io.codec
A simple Codec implementation that turns a Buffer into a byte[] and visa-versa.
ByteArrayCodec() - Constructor for class reactor.io.codec.ByteArrayCodec
 
byteBuffer() - Method in class reactor.io.buffer.Buffer
Return the underlying ByteBuffer.

C

CachableRegistration<K,V> - Class in reactor.bus.registry
 
CachableRegistration(Selector<K>, V, Runnable) - Constructor for class reactor.bus.registry.CachableRegistration
 
cache() - Method in class reactor.rx.Stream
Cache all signal to this Stream and release them on request that will observe any values accepted by this Stream.
CACHE_CONTROL - Static variable in interface reactor.io.net.http.model.Headers
The HTTP Cache-Control header field name.
CacheAction<T> - Class in reactor.rx.action.aggregation
 
CacheAction() - Constructor for class reactor.rx.action.aggregation.CacheAction
 
cachedDispatcher() - Static method in class reactor.Environment
Obtain a cached dispatcher out of this#PROCESSORS maximum pooled.
cachedDispatchers(String) - Static method in class reactor.Environment
Obtain a dispatcher supplier into the context environment.
cachedDispatchers() - Static method in class reactor.Environment
Obtain the default dispatcher supplier from the context environment.
cachedDispatchers(String, DispatcherSupplier) - Static method in class reactor.Environment
Register a dispatcher supplier into the context environment.
cacheMiss(Object) - Method in class reactor.bus.registry.CachingRegistry
 
CachingRegistry<K,V> - Class in reactor.bus.registry
Implementation of Registry that uses a partitioned cache that partitions on thread id.
call(Function<T, V>, T) - Static method in class reactor.groovy.ext.BusExtensions
 
call(Consumer<T>, T) - Static method in class reactor.groovy.ext.BusExtensions
 
call(Supplier<T>) - Static method in class reactor.groovy.ext.BusExtensions
 
callback() - Method in class reactor.bus.support.CallbackEvent
Trigger callback with current payload
CallbackAction<T> - Class in reactor.rx.action.passive
 
CallbackAction(Consumer<? super T>, Consumer<Void>) - Constructor for class reactor.rx.action.passive.CallbackAction
 
CallbackEvent<T> - Class in reactor.bus.support
Simple Event implementation that attaches a callback to an Event and passes it to a delegate Consumer.
CallbackEvent(T, Consumer) - Constructor for class reactor.bus.support.CallbackEvent
 
CallbackEvent(Event.Headers, T, Consumer) - Constructor for class reactor.bus.support.CallbackEvent
 
CallbackEvent(Event.Headers, T, Consumer, Consumer<Throwable>) - Constructor for class reactor.bus.support.CallbackEvent
 
calm() - Method in class reactor.core.dispatch.RingBufferDispatcher
 
calm() - Method in class reactor.core.dispatch.wait.AgileWaitingStrategy
 
calm() - Method in interface reactor.core.dispatch.wait.WaitingMood
Turn the mood into eco CPU demand mode to save resources from the underlying component.
calm() - Method in class reactor.core.dispatch.WorkQueueDispatcher
 
cancel() - Method in class reactor.bus.registry.CachableRegistration
 
cancel() - Method in interface reactor.bus.registry.Registration
Cancel this Registration by removing it from its registry.
cancel() - Method in class reactor.bus.timer.EventTimer
 
cancel() - Method in class reactor.core.reactivestreams.SerializedSubscriber
 
cancel() - Method in class reactor.core.reactivestreams.SubscriberBarrier
 
cancel() - Method in class reactor.core.reactivestreams.SubscriptionWithContext
 
cancel() - Method in interface reactor.fn.Pausable
Cancel this Pausable.
cancel() - Method in class reactor.fn.timer.HashWheelTimer
Cancel current Timer
cancel() - Method in class reactor.fn.timer.HashWheelTimer.TimerPausable
Cancel the registration
cancel() - Method in interface reactor.fn.timer.Timer
Cancel this timer by interrupting the task thread.
cancel() - Method in class reactor.groovy.support.ClosureEventConsumer
 
cancel() - Method in class reactor.rx.action.Action
 
cancel() - Method in class reactor.rx.action.combination.ConcatAction
 
cancel() - Method in class reactor.rx.action.combination.FanInAction
 
cancel() - Method in class reactor.rx.action.combination.FanInAction.InnerSubscriber
 
cancel() - Method in class reactor.rx.action.combination.FanInSubscription
 
cancel() - Method in class reactor.rx.action.combination.FanInSubscription.InnerSubscription
 
cancel() - Method in class reactor.rx.action.combination.SwitchAction
 
cancel() - Method in class reactor.rx.action.combination.SwitchAction.SwitchSubscriber
 
cancel() - Method in class reactor.rx.action.CompositeAction
 
cancel() - Method in interface reactor.rx.action.Control
Stop consuming signals from upstream.
cancel() - Method in class reactor.rx.action.passive.LoggerAction
 
cancel() - Method in class reactor.rx.action.support.TapAndControls
 
cancel() - Method in class reactor.rx.broadcast.Broadcaster
 
cancel() - Method in class reactor.rx.subscription.DropSubscription
 
cancel() - Method in class reactor.rx.subscription.FanOutSubscription
 
cancel() - Method in class reactor.rx.subscription.PushSubscription
 
cancel() - Method in class reactor.rx.subscription.support.WrappedSubscription
 
cancelAfterUse() - Method in class reactor.bus.registry.CachableRegistration
 
cancelAfterUse() - Method in interface reactor.bus.registry.Registration
Cancel this Registration after it has been selected and used.
cancelAfterUse() - Method in class reactor.fn.timer.HashWheelTimer.TimerPausable
Cancel this HashWheelTimer.TimerPausable after it has been selected and used.
CancelException - Exception in reactor.core.processor
An exception signal from downstream subscribers consuming data when their state is denying any additional event.
cancelSubscription(PushSubscription<O>) - Method in class reactor.rx.action.Action
-------------------------------------------------------------------------------------------------------- INTERNALS --------------------------------------------------------------------------------------------------------
cancelSubscription(PushSubscription<O>) - Method in class reactor.rx.Stream
Try cleaning a given subscription from the stream references.
capacity() - Method in class reactor.io.buffer.Buffer
Provides the current capacity of the internal ByteBuffer.
capacity - Variable in class reactor.rx.action.Action
 
capacity(long) - Method in class reactor.rx.action.Action
-------------------------------------------------------------------------------------------------------- ACTION MODIFIERS --------------------------------------------------------------------------------------------------------
capacity(long) - Method in class reactor.rx.action.combination.DynamicMergeAction
 
capacity(long) - Method in class reactor.rx.action.CompositeAction
 
capacity(long) - Method in class reactor.rx.broadcast.Broadcaster
 
capacity(long) - Method in class reactor.rx.Stream
Bind the stream to a given volume of in-flight data: - An Action will request up to the defined volume upstream
capacity - Variable in class reactor.rx.subscription.DropSubscription
 
capacity() - Method in class reactor.rx.subscription.ReactiveSubscription
 
CAPACITY_UPDATER - Static variable in class reactor.rx.subscription.DropSubscription
 
cast(Class<E>) - Method in class reactor.rx.Stream
Cast the current Stream flowing data type into a target class type.
chain(Consumer<T>...) - Static method in class reactor.fn.Functions
Deprecated.
Chain a set of Consumers together into a single Consumer.
CHANNEL_REF - Static variable in class reactor.io.net.impl.netty.NettyChannelHandlerBridge
 
channelActive(ChannelHandlerContext) - Method in class reactor.io.net.impl.netty.http.NettyHttpClientHandler
 
channelActive(ChannelHandlerContext) - Method in class reactor.io.net.impl.netty.http.NettyHttpServerHandler
 
channelActive(ChannelHandlerContext) - Method in class reactor.io.net.impl.netty.http.NettyHttpWSClientHandler
 
channelActive(ChannelHandlerContext) - Method in class reactor.io.net.impl.netty.NettyChannelHandlerBridge
 
channelInactive(ChannelHandlerContext) - Method in class reactor.io.net.impl.netty.NettyChannelHandlerBridge
 
ChannelInputSubscriberEvent(Subscriber<IN>) - Constructor for class reactor.io.net.impl.netty.NettyChannelHandlerBridge.ChannelInputSubscriberEvent
 
channelRead(ChannelHandlerContext, Object) - Method in class reactor.io.net.impl.netty.http.NettyHttpClientHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class reactor.io.net.impl.netty.http.NettyHttpServerHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class reactor.io.net.impl.netty.http.NettyHttpWSClientHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class reactor.io.net.impl.netty.http.NettyHttpWSServerHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class reactor.io.net.impl.netty.NettyChannelHandlerBridge
 
channelReadComplete(ChannelHandlerContext) - Method in class reactor.io.net.impl.netty.NettyChannelHandlerBridge
 
ChannelStream<IN,OUT> - Class in reactor.io.net
An abstract ReactorChannel implementation that handles the basic interaction and behave as a Stream.
ChannelStream(Environment, Codec<Buffer, IN, OUT>, long, Dispatcher) - Constructor for class reactor.io.net.ChannelStream
 
channelStream - Variable in class reactor.io.net.impl.netty.NettyChannelHandlerBridge
 
channelSubscription - Variable in class reactor.io.net.impl.netty.NettyChannelHandlerBridge
 
checkDynamicMerge() - Method in class reactor.rx.action.combination.FanInAction
 
checkRequest(long) - Static method in class reactor.rx.action.Action
 
checkResolution(long, long) - Static method in class reactor.fn.timer.TimeUtils
 
chronicle - Variable in class reactor.rx.stream.io.ChronicleReaderStream
 
chronicle() - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
ChronicleQueuePersistor<T> - Class in reactor.io.queue
A QueuePersistor implementation that uses a Java Chronicle IndexedChronicle to persist items in the queue.
ChronicleQueuePersistor(String) - Constructor for class reactor.io.queue.ChronicleQueuePersistor
Create an ChronicleQueuePersistor based on the given base path.
ChronicleQueuePersistor(String, Codec<Buffer, T, T>, boolean, boolean, ChronicleQueueBuilder) - Constructor for class reactor.io.queue.ChronicleQueuePersistor
Create an ChronicleQueuePersistor based on the given base path, encoder and decoder.
ChronicleReaderStream<K,V> - Class in reactor.rx.stream.io
Implementation of a Dispatcher that uses a IndexedChronicle to queue tasks to execute.
ChronicleReaderStream(String) - Constructor for class reactor.rx.stream.io.ChronicleReaderStream
Create a chronicle dispatcher
ChronicleReaderStream(String, Chronicle) - Constructor for class reactor.rx.stream.io.ChronicleReaderStream
Create a chronicle dispatcher
ChronicleReaderStream(String, Chronicle, Codec<Buffer, K, K>, Codec<Buffer, V, V>) - Constructor for class reactor.rx.stream.io.ChronicleReaderStream
 
ChronicleStream<K,V> - Class in reactor.rx.stream.io
 
ChronicleStream(String) - Constructor for class reactor.rx.stream.io.ChronicleStream
 
ChronicleStream(String, int) - Constructor for class reactor.rx.stream.io.ChronicleStream
 
ChronicleStream(String, int, Chronicle) - Constructor for class reactor.rx.stream.io.ChronicleStream
 
ChronicleStream(String, int, Chronicle, Codec<Buffer, K, K>, Codec<Buffer, V, V>) - Constructor for class reactor.rx.stream.io.ChronicleStream
 
ClassSelector - Class in reactor.bus.selector
Implementation of Selector that uses Class.isAssignableFrom(Class) to determine a match.
ClassSelector(Class<?>) - Constructor for class reactor.bus.selector.ClassSelector
Creates a new ClassSelector that will match keys that are the same as, or are a super type of the given type, i.e. the key is assignable according to Class.isAssignableFrom(Class).
clear() - Method in class reactor.bus.registry.CachingRegistry
 
clear() - Method in interface reactor.bus.registry.Registry
Clear the Registry, resetting its state and calling Registration.cancel() for any active Registration.
clear() - Method in class reactor.bus.registry.SimpleCachingRegistry
 
clear() - Method in class reactor.core.queue.internal.MpscLinkedQueue
 
clear() - Method in class reactor.io.buffer.Buffer
Clear the internal ByteBuffer by setting the Buffer.position(int) to 0 and the limit to the current capacity.
clear() - Method in interface reactor.io.net.http.model.WritableHeaders
 
clear() - Method in class reactor.io.net.impl.netty.http.NettyHttpHeaders
 
clear() - Method in class reactor.io.net.impl.netty.http.NettyHttpResponseHeaders
 
clear() - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
clear() - Method in class reactor.rx.stream.io.ChronicleStream
 
clearAllFilters() - Method in class reactor.logback.AsyncAppender
 
clearMaybe() - Method in class reactor.core.queue.internal.MpscLinkedQueueNode
Sets the element this node contains to null so that the node can be used as a tombstone.
clearOnStart(boolean) - Method in class reactor.io.queue.spec.PersistentQueueSpec
 
ClientSocketOptions - Class in reactor.io.net.config
 
ClientSocketOptions() - Constructor for class reactor.io.net.config.ClientSocketOptions
 
clone() - Method in class reactor.bus.selector.ObjectSelector
 
close() - Method in class reactor.Environment
 
close() - Method in class reactor.io.buffer.Buffer
 
close() - Method in class reactor.io.IO.FileContext
 
close() - Method in class reactor.io.net.impl.zmq.ZeroMQChannelStream
 
close(Consumer<Void>) - Method in interface reactor.io.net.ReactorChannel.ConsumerSpec
Assign a Runnable to be invoked when the channel is closed.
close() - Method in class reactor.io.queue.ChronicleQueuePersistor
Close the underlying chronicles.
close() - Method in class reactor.io.queue.InMemoryQueuePersistor
 
close() - Method in class reactor.io.queue.PersistentQueue
Close the underlying QueuePersistor and release any resources.
close() - Method in interface reactor.io.queue.QueuePersistor
Release any internal resources used by the persistence mechanism.
CLOSE_MSG - Static variable in class reactor.io.net.impl.zmq.ZeroMQWorker
 
ClosureConsumer<T> - Class in reactor.groovy.support
 
ClosureConsumer(Closure) - Constructor for class reactor.groovy.support.ClosureConsumer
 
ClosureEventConsumer<T> - Class in reactor.groovy.support
 
ClosureEventConsumer(Closure) - Constructor for class reactor.groovy.support.ClosureEventConsumer
 
ClosureEventConsumer.ReplyDecorator - Class in reactor.groovy.support
 
ClosureEventFunction<K,V> - Class in reactor.groovy.support
 
ClosureEventFunction(Closure<V>) - Constructor for class reactor.groovy.support.ClosureEventFunction
 
ClosureFunction<K,V> - Class in reactor.groovy.support
 
ClosureFunction(Closure) - Constructor for class reactor.groovy.support.ClosureFunction
 
ClosurePredicate<V> - Class in reactor.groovy.support
 
ClosurePredicate(Closure<Boolean>) - Constructor for class reactor.groovy.support.ClosurePredicate
 
ClosureReduce<T,V> - Class in reactor.groovy.support
 
ClosureReduce(Closure<V>) - Constructor for class reactor.groovy.support.ClosureReduce
 
ClosureSupplier<V> - Class in reactor.groovy.support
 
ClosureSupplier(Closure) - Constructor for class reactor.groovy.support.ClosureSupplier
 
ClosureTupleConsumer - Class in reactor.groovy.support
Invokes a Closure using the contents of the incoming Tuple as the arguments.
ClosureTupleConsumer(Closure) - Constructor for class reactor.groovy.support.ClosureTupleConsumer
 
Codec<SRC,IN,OUT> - Class in reactor.io.codec
Implementations of a Codec are responsible for decoding a SRC into an instance of IN and passing that to the given Consumer.
Codec() - Constructor for class reactor.io.codec.Codec
Create a new Codec set with a \0 delimiter to finish any Buffer encoded value or scan for delimited decoded Buffers.
Codec(Byte) - Constructor for class reactor.io.codec.Codec
A delimiter can be used to trail any decoded buffer or to finalize encoding from any incoming value
codec(Codec<Buffer, T, T>) - Method in class reactor.io.net.impl.zmq.tcp.ZeroMQ
 
codec(Codec<Buffer, IN, OUT>) - Method in class reactor.io.net.Spec.HttpClientSpec
The Codec to use to encode and decode data.
codec - Variable in class reactor.io.net.Spec.PeerSpec
 
codec(Codec<Buffer, IN, OUT>) - Method in class reactor.io.net.Spec.PeerSpec
The Codec to use to encode and decode data.
codec(Codec<Buffer, IN, OUT>) - Method in class reactor.io.net.Spec.TcpClientSpec
The Codec to use to encode and decode data.
codec() - Method in class reactor.io.queue.ChronicleQueuePersistor
 
codec(Codec<Buffer, T, T>) - Method in class reactor.io.queue.spec.PersistentQueueSpec
 
collect(List<Supplier<T>>) - Static method in class reactor.fn.Suppliers
Deprecated.
Create a Supplier that aggregates the given list of suppliers by calling each one, in turn, until the supplier returns null.
combine() - Method in class reactor.rx.action.Action
 
combine() - Method in class reactor.rx.Stream
Combine the most ancient upstream action to act as the Subscriber input component and the current stream to act as the Publisher.
combine() - Method in class reactor.rx.stream.LiftStream
 
combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, Function<Tuple2<T1, T2>, ? extends V>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the combination of the most recent published values from all publishers.
combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Function<Tuple3<T1, T2, T3>, ? extends V>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the combination of the most recent published values from all publishers.
combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Function<Tuple4<T1, T2, T3, T4>, V>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the combination of the most recent published values from all publishers.
combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Function<Tuple5<T1, T2, T3, T4, T5>, V>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the combination of the most recent published values from all publishers.
combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Publisher<? extends T6>, Function<Tuple6<T1, T2, T3, T4, T5, T6>, V>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the combination of the most recent published values from all publishers.
combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Publisher<? extends T6>, Publisher<? extends T7>, Function<Tuple7<T1, T2, T3, T4, T5, T6, T7>, V>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the combination of the most recent published values from all publishers.
combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Publisher<? extends T6>, Publisher<? extends T7>, Publisher<? extends T8>, Function<Tuple8<T1, T2, T3, T4, T5, T6, T7, T8>, ? extends V>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the combination of the most recent published values from all publishers.
combineLatest(List<? extends Publisher<?>>, Function<TUPLE, ? extends V>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the combination of the most recent published values from all publishers.
combineLatest(Publisher<? extends Publisher<E>>, Function<TUPLE, ? extends V>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the combination of the most recent published values from all publishers.
CombineLatestAction<O,V,TUPLE extends Tuple> - Class in reactor.rx.action.combination
 
CombineLatestAction(Dispatcher, Function<TUPLE, ? extends V>, List<? extends Publisher<? extends O>>) - Constructor for class reactor.rx.action.combination.CombineLatestAction
 
CombineLatestAction.InnerSubscriber<O,V> - Class in reactor.rx.action.combination
 
CombineLatestAction.Zippable<O> - Class in reactor.rx.action.combination
 
CommonSocketOptions<SO extends CommonSocketOptions<? super SO>> - Class in reactor.io.net.config
Encapsulates common socket options.
CommonSocketOptions() - Constructor for class reactor.io.net.config.CommonSocketOptions
 
compact() - Method in class reactor.io.buffer.Buffer
Compact the underlying ByteBuffer.
compareTo(Object) - Method in class reactor.fn.timer.HashWheelTimer.TimerPausable
 
compareTo(ReactorBuilder.SelectorProcessor) - Method in class reactor.groovy.config.ReactorBuilder.SelectorProcessor
 
compareTo(Buffer) - Method in class reactor.io.buffer.Buffer
 
CompletableBlockingQueue<T> - Class in reactor.core.queue
A LinkedQueue that supports a terminal state.
CompletableBlockingQueue(int) - Constructor for class reactor.core.queue.CompletableBlockingQueue
 
CompletableLinkedQueue<T> - Class in reactor.core.queue
A LinkedQueue that supports a terminal state.
CompletableLinkedQueue() - Constructor for class reactor.core.queue.CompletableLinkedQueue
 
CompletableQueue<T> - Interface in reactor.core.queue
Deprecated.
complete() - Method in class reactor.core.queue.CompletableBlockingQueue
 
complete() - Method in class reactor.core.queue.CompletableLinkedQueue
 
complete() - Method in interface reactor.core.queue.CompletableQueue
Deprecated.
Mark this queue as complete
complete() - Method in class reactor.io.queue.PersistentQueue
 
complete() - Static method in class reactor.rx.action.Signal
Creates and returns a Signal of variety Type.COMPLETE.
completeAccepted() - Method in class reactor.rx.Promise
 
COMPLETING - Static variable in class reactor.rx.action.combination.FanInAction
 
CompositeAction<E,O> - Class in reactor.rx.action
Create a Processor where a given head/tail couple is provided as a Stream (Input upstream) and Action (Output downstream).
CompositeAction(Action<E, ?>, Action<?, O>) - Constructor for class reactor.rx.action.CompositeAction
 
CompressionCodec<IN,OUT> - Class in reactor.io.codec.compress
 
CompressionCodec(Codec<Buffer, IN, OUT>) - Constructor for class reactor.io.codec.compress.CompressionCodec
 
concat(Iterable<? extends Publisher<? extends T>>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are generated by the passed publishers.
concat(Publisher<? extends Publisher<? extends T>>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are generated by the passed publishers.
concat(Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are generated by the passed publishers.
concat(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are generated by the passed publishers.
concat(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are generated by the passed publishers.
concat(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are generated by the passed publishers.
concat(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are generated by the passed publishers.
concat(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are generated by the passed publishers.
concat(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are generated by the passed publishers.
ConcatAction<T> - Class in reactor.rx.action.combination
 
ConcatAction() - Constructor for class reactor.rx.action.combination.ConcatAction
 
concatMap(Function<? super O, Publisher<? extends V>>) - Method in class reactor.rx.Stream
Assign the given Function to transform the incoming value T into a Stream<O,V> and pass it into another Stream.
concatWith(Publisher<? extends O>) - Method in class reactor.rx.Stream
Stream.lift(Supplier) all the nested Publisher values from this current upstream and then on complete consume from the passed publisher.
config() - Static method in class reactor.bus.EventBus
Create a new EventBusSpec to configure a Reactor.
ConfigurationReader - Interface in reactor.core.config
A ConfigurationReader is used to read Reactor configuration.
configure(Dispatcher, Environment) - Method in class reactor.bus.spec.DispatcherComponentSpec
 
configure(EventBus, Environment) - Method in class reactor.bus.spec.EventBusSpec
 
configure(EventBus, Environment) - Method in class reactor.bus.spec.EventRoutingComponentSpec
 
configure(Dispatcher, Environment) - Method in class reactor.bus.spec.EventRoutingComponentSpec
 
configure(ZMQ.Socket) - Method in class reactor.io.net.impl.zmq.ZeroMQWorker
 
configure(Dispatcher, Environment) - Method in class reactor.io.net.Spec.DatagramServerSpec
 
configure(Dispatcher, Environment) - Method in class reactor.io.net.Spec.HttpClientSpec
 
configure(Dispatcher, Environment) - Method in class reactor.io.net.Spec.HttpServerSpec
 
configure(Dispatcher, Environment) - Method in class reactor.io.net.Spec.TcpClientSpec
 
configure(Dispatcher, Environment) - Method in class reactor.io.net.Spec.TcpServerSpec
 
CONFLICT - Static variable in class reactor.io.net.http.model.Status
409 Conflict
CONNECT - Static variable in class reactor.io.net.http.model.Method
 
connect(String, int) - Method in class reactor.io.net.Spec.HttpClientSpec
The host and port to which this client should connect.
connect(InetSocketAddress) - Method in class reactor.io.net.Spec.HttpClientSpec
The address to which this client should connect.
connect(Supplier<InetSocketAddress>) - Method in class reactor.io.net.Spec.HttpClientSpec
The address to which this client should connect.
connect(String, int) - Method in class reactor.io.net.Spec.TcpClientSpec
The host and port to which this client should connect.
connect(InetSocketAddress) - Method in class reactor.io.net.Spec.TcpClientSpec
The address to which this client should connect.
connect(Supplier<InetSocketAddress>) - Method in class reactor.io.net.Spec.TcpClientSpec
The eventual address to which this client should connect.
connectAddress - Variable in class reactor.io.net.tcp.TcpClient
 
connectAddresses() - Method in class reactor.io.net.impl.zmq.ZeroMQClientSocketOptions
 
connectAddresses(String) - Method in class reactor.io.net.impl.zmq.ZeroMQClientSocketOptions
 
CONNECTION - Static variable in interface reactor.io.net.http.model.Headers
The HTTP Connection header field name.
consume() - Method in class reactor.rx.Stream
Instruct the stream to request the produced subscription indefinitely.
consume(long) - Method in class reactor.rx.Stream
Instruct the action to request upstream subscription if any for N elements.
consume(Consumer<? super O>) - Method in class reactor.rx.Stream
Attach a Consumer to this Stream that will consume any values accepted by this Stream.
consume(Consumer<? super O>, Consumer<? super Throwable>) - Method in class reactor.rx.Stream
Attach 2 Consumer to this Stream that will consume any values signaled by this Stream.
consume(Consumer<? super O>, Consumer<? super Throwable>, Consumer<Void>) - Method in class reactor.rx.Stream
Attach 3 Consumer to this Stream that will consume any values signaled by this Stream.
consumeError(Throwable) - Method in class reactor.bus.Event
Consumes error, using a producer defined callback
consumeLater() - Method in class reactor.rx.Stream
Defer a Controls operations ready to be requested.
consumeOn(Dispatcher, Consumer<? super O>) - Method in class reactor.rx.Stream
Attach a Consumer to this Stream that will consume any values accepted by this Stream.
consumeOn(Dispatcher, Consumer<? super O>, Consumer<? super Throwable>) - Method in class reactor.rx.Stream
Attach 2 Consumer to this Stream that will consume any values signaled by this Stream.
consumeOn(Dispatcher, Consumer<? super O>, Consumer<? super Throwable>, Consumer<Void>) - Method in class reactor.rx.Stream
Attach 3 Consumer to this Stream that will consume any values signaled by this Stream.
Consumer<T> - Interface in reactor.fn
Implementations accept a given value and perform work on the argument.
consumer(Runnable) - Static method in class reactor.fn.Functions
Deprecated.
Wrap the given Runnable and compose a new Consumer.
CONSUMER_UPDATER - Static variable in class reactor.rx.stream.io.ChronicleReaderStream
 
ConsumerAction<T> - Class in reactor.rx.action.terminal
 
ConsumerAction(long, Dispatcher, Consumer<? super T>, Consumer<? super Throwable>, Consumer<Void>) - Constructor for class reactor.rx.action.terminal.ConsumerAction
 
ConsumerFilteringRouter - Class in reactor.bus.routing
An Router that filters consumers before routing events to them.
ConsumerFilteringRouter(Filter) - Constructor for class reactor.bus.routing.ConsumerFilteringRouter
Creates a new ConsumerFilteringEventRouter that will use the filter to filter consumers.
consumerNotFoundHandler(Consumer<Object>) - Method in class reactor.bus.spec.EventRoutingComponentSpec
Configures the callback to invoke if a notification key is sent into this component and there are no consumers registered to respond to it.
consumerRegistry(Registry<Object, Consumer<? extends Event<?>>>) - Method in class reactor.bus.spec.EventRoutingComponentSpec
Configures the Registry to use when creating this component.
consumers - Variable in class reactor.rx.stream.io.ChronicleReaderStream
 
contains(String) - Method in class reactor.bus.Event.Headers
Determine whether the headers contain a value for the given name.
contains(Object) - Method in class reactor.core.queue.internal.MpscLinkedQueue
 
contains(String) - Method in interface reactor.io.net.http.model.ReadableHeaders
 
contains(String, String, boolean) - Method in interface reactor.io.net.http.model.ReadableHeaders
 
contains(String) - Method in class reactor.io.net.impl.netty.http.NettyHttpHeaders
 
contains(String, String, boolean) - Method in class reactor.io.net.impl.netty.http.NettyHttpHeaders
 
contains(String) - Method in class reactor.io.net.impl.netty.http.NettyHttpResponseHeaders
 
contains(String, String, boolean) - Method in class reactor.io.net.impl.netty.http.NettyHttpResponseHeaders
 
contains(PushSubscription<O>) - Method in class reactor.rx.subscription.FanOutSubscription
 
containsAll(Collection<?>) - Method in class reactor.core.queue.internal.MpscLinkedQueue
 
containsKey(Object) - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
containsValue(Object) - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
CONTENT_DISPOSITION - Static variable in interface reactor.io.net.http.model.ResponseHeaders
The HTTP Content-Disposition header field name
CONTENT_ENCODING - Static variable in interface reactor.io.net.http.model.ResponseHeaders
The HTTP Content-Encoding header field name.
CONTENT_LANGUAGE - Static variable in interface reactor.io.net.http.model.ResponseHeaders
The HTTP Content-Language header field name.
CONTENT_LENGTH - Static variable in interface reactor.io.net.http.model.Headers
The HTTP Content-Length header field name.
CONTENT_LOCATION - Static variable in interface reactor.io.net.http.model.ResponseHeaders
The HTTP Content-Location header field name.
CONTENT_RANGE - Static variable in interface reactor.io.net.http.model.ResponseHeaders
The HTTP Content-Range header field name.
CONTENT_TYPE - Static variable in interface reactor.io.net.http.model.Headers
The HTTP Content-Type header field name.
contentLength(long) - Method in interface reactor.io.net.http.model.WritableHeaders
 
contentLength(long) - Method in class reactor.io.net.impl.netty.http.NettyHttpHeaders
 
contentLength(long) - Method in class reactor.io.net.impl.netty.http.NettyHttpResponseHeaders
 
context - Variable in class reactor.core.dispatch.AbstractLifecycleDispatcher
 
context - Variable in class reactor.core.reactivestreams.SubscriberWithContext
 
context() - Method in class reactor.core.reactivestreams.SubscriberWithContext
The stateful context C
context - Variable in class reactor.core.reactivestreams.SubscriptionWithContext
 
context() - Method in class reactor.core.reactivestreams.SubscriptionWithContext
The stateful context C
context() - Method in class reactor.io.net.impl.zmq.ZeroMQClientSocketOptions
Get the ZContext to use for IO.
context(ZContext) - Method in class reactor.io.net.impl.zmq.ZeroMQClientSocketOptions
Set the ZContext to use for IO.
context() - Method in class reactor.io.net.impl.zmq.ZeroMQServerSocketOptions
Get the ZMQ.Context to use for IO.
context(ZContext) - Method in class reactor.io.net.impl.zmq.ZeroMQServerSocketOptions
Set the ZMQ.Context to use for IO.
CONTINUE - Static variable in class reactor.io.net.http.model.Status
100 Continue
control(Stream<E>, Consumer<Tuple2<Action<I, O>, ? super E>>) - Method in class reactor.rx.action.Action
Consume a Stream to allow for dynamic Action update.
Control - Interface in reactor.rx.action
An interface generally associated with a Stream terminal action such as Stream.consume(reactor.fn.Consumer)
convertBufferToByteBuff(ChannelHandlerContext, Buffer) - Static method in class reactor.io.net.impl.netty.NettyChannelHandlerBridge
 
COOKIE - Static variable in interface reactor.io.net.http.model.HttpHeaders
The HTTP Cookie header field name.
copy() - Method in class reactor.bus.Event
Create a copy of this event, reusing same headers, data and replyTo
copy(E) - Method in class reactor.bus.Event
Create a copy of this event, reusing same headers and replyTo
copy(X) - Method in class reactor.bus.EventBus.ReplyToEvent
 
copy(X) - Method in class reactor.bus.support.CallbackEvent
 
copy() - Method in class reactor.io.buffer.Buffer
Create a new Buffer by copying the underlying ByteBuffer into a newly-allocated Buffer.
count() - Method in class reactor.rx.Stream
Count accepted events for each batch and pass each accumulated long to the .
count(long) - Method in class reactor.rx.Stream
Count accepted events for each batch and pass each accumulated long to the .
CountAction<T> - Class in reactor.rx.action.metrics
 
CountAction(long) - Constructor for class reactor.rx.action.metrics.CountAction
 
create() - Static method in class reactor.bus.EventBus
Create a new synchronous EventBus
create(Environment) - Static method in class reactor.bus.EventBus
Create a new EventBus using the given Environment.
create(Dispatcher) - Static method in class reactor.bus.EventBus
Create a new EventBus using the given Dispatcher.
create(Environment, String) - Static method in class reactor.bus.EventBus
Create a new EventBus using the given Environment and dispatcher name.
create(Environment, Dispatcher) - Static method in class reactor.bus.EventBus
Create a new EventBus using the given Environment and Dispatcher.
create() - Static method in class reactor.bus.registry.Registries
 
create(boolean, boolean, Consumer<K>) - Static method in class reactor.bus.registry.Registries
 
create() - Static method in class reactor.core.processor.RingBufferProcessor
Create a new RingBufferProcessor using ReactorProcessor.SMALL_BUFFER_SIZE backlog size, blockingWait Strategy and auto-cancel.
create(boolean) - Static method in class reactor.core.processor.RingBufferProcessor
Create a new RingBufferProcessor using ReactorProcessor.SMALL_BUFFER_SIZE backlog size, blockingWait Strategy and the passed auto-cancel setting.
create(ExecutorService) - Static method in class reactor.core.processor.RingBufferProcessor
Create a new RingBufferProcessor using ReactorProcessor.SMALL_BUFFER_SIZE backlog size, blockingWait Strategy and auto-cancel.
create(ExecutorService, boolean) - Static method in class reactor.core.processor.RingBufferProcessor
Create a new RingBufferProcessor using ReactorProcessor.SMALL_BUFFER_SIZE backlog size, blockingWait Strategy and the passed auto-cancel setting.
create(String, int) - Static method in class reactor.core.processor.RingBufferProcessor
Create a new RingBufferProcessor using ReactorProcessor.SMALL_BUFFER_SIZE backlog size, blockingWait Strategy and the passed auto-cancel setting.
create(String, int, boolean) - Static method in class reactor.core.processor.RingBufferProcessor
Create a new RingBufferProcessor using the blockingWait Strategy, passed backlog size, and auto-cancel settings.
create(ExecutorService, int) - Static method in class reactor.core.processor.RingBufferProcessor
Create a new RingBufferProcessor using passed backlog size, blockingWait Strategy and will auto-cancel.
create(ExecutorService, int, boolean) - Static method in class reactor.core.processor.RingBufferProcessor
Create a new RingBufferProcessor using passed backlog size, blockingWait Strategy and the auto-cancel argument.
create(String, int, WaitStrategy) - Static method in class reactor.core.processor.RingBufferProcessor
Create a new RingBufferProcessor using passed backlog size, wait strategy and will auto-cancel.
create(String, int, WaitStrategy, boolean) - Static method in class reactor.core.processor.RingBufferProcessor
Create a new RingBufferProcessor using passed backlog size, wait strategy and auto-cancel settings.
create(ExecutorService, int, WaitStrategy) - Static method in class reactor.core.processor.RingBufferProcessor
Create a new RingBufferProcessor using passed backlog size, wait strategy and will auto-cancel.
create(ExecutorService, int, WaitStrategy, boolean) - Static method in class reactor.core.processor.RingBufferProcessor
Create a new RingBufferProcessor using passed backlog size, wait strategy and auto-cancel settings.
create() - Static method in class reactor.core.processor.RingBufferWorkProcessor
Create a new RingBufferWorkProcessor using ReactorProcessor.SMALL_BUFFER_SIZE backlog size, blockingWait Strategy and auto-cancel.
create(boolean) - Static method in class reactor.core.processor.RingBufferWorkProcessor
Create a new RingBufferWorkProcessor using ReactorProcessor.SMALL_BUFFER_SIZE backlog size, blockingWait Strategy and the passed auto-cancel setting.
create(ExecutorService) - Static method in class reactor.core.processor.RingBufferWorkProcessor
Create a new RingBufferWorkProcessor using ReactorProcessor.SMALL_BUFFER_SIZE backlog size, blockingWait Strategy and auto-cancel.
create(ExecutorService, boolean) - Static method in class reactor.core.processor.RingBufferWorkProcessor
Create a new RingBufferWorkProcessor using ReactorProcessor.SMALL_BUFFER_SIZE backlog size, blockingWait Strategy and the passed auto-cancel setting.
create(String, int) - Static method in class reactor.core.processor.RingBufferWorkProcessor
Create a new RingBufferProcessor using the passed buffer size, blockingWait Strategy and auto-cancel.
create(String, int, boolean) - Static method in class reactor.core.processor.RingBufferWorkProcessor
Create a new RingBufferProcessor using the passed buffer size, blockingWait Strategy and the passed auto-cancel setting.
create(ExecutorService, int) - Static method in class reactor.core.processor.RingBufferWorkProcessor
Create a new RingBufferProcessor using the passed buffer size, blockingWait Strategy and auto-cancel.
create(ExecutorService, int, boolean) - Static method in class reactor.core.processor.RingBufferWorkProcessor
Create a new RingBufferWorkProcessor using the passed buffer size, blockingWait Strategy and auto-cancel.
create(String, int, WaitStrategy) - Static method in class reactor.core.processor.RingBufferWorkProcessor
Create a new RingBufferWorkProcessor using the passed buffer size, blockingWait Strategy and auto-cancel.
create(String, int, WaitStrategy, boolean) - Static method in class reactor.core.processor.RingBufferWorkProcessor
Create a new RingBufferWorkProcessor using the passed buffer size, blockingWait Strategy and auto-cancel settings.
create(ExecutorService, int, WaitStrategy) - Static method in class reactor.core.processor.RingBufferWorkProcessor
Create a new RingBufferWorkProcessor using the passed buffer size and blockingWait Strategy settings but will auto-cancel.
create(ExecutorService, int, WaitStrategy, boolean) - Static method in class reactor.core.processor.RingBufferWorkProcessor
Create a new RingBufferWorkProcessor using the passed buffer size, wait strategy and auto-cancel settings.
create(String) - Static method in class reactor.core.processor.util.SingleUseExecutor
 
create() - Static method in class reactor.core.queue.internal.MpscLinkedQueue
Create a new Queue which is safe to use for multiple producers (different threads) and a single consumer (one thread!).
create(BiConsumer<Long, SubscriberWithContext<T, Void>>) - Static method in class reactor.core.reactivestreams.PublisherFactory
Create a Publisher reacting on requests with the passed BiConsumer
create(BiConsumer<Long, SubscriberWithContext<T, C>>, Function<Subscriber<? super T>, C>) - Static method in class reactor.core.reactivestreams.PublisherFactory
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.
create(BiConsumer<Long, SubscriberWithContext<T, C>>, Function<Subscriber<? super T>, C>, Consumer<C>) - Static method in class reactor.core.reactivestreams.PublisherFactory
Create a Publisher reacting on requests with the passed BiConsumer.
create(Subscriber<? super T>) - Static method in class reactor.core.reactivestreams.SerializedSubscriber
 
create(Consumer<Subscription>) - Static method in class reactor.core.reactivestreams.SubscriberFactory
Create a Subscriber reacting onSubscribe with the passed Consumer
create(Function<Subscription, C>, BiConsumer<T, SubscriptionWithContext<C>>) - Static method in class reactor.core.reactivestreams.SubscriberFactory
Create a Subscriber reacting onSubscribe and onNext, eventually sharing a context.
create(Function<Subscription, C>, BiConsumer<T, SubscriptionWithContext<C>>, BiConsumer<Throwable, C>) - Static method in class reactor.core.reactivestreams.SubscriberFactory
Create a Subscriber reacting onNext, onError.
create(Function<Subscription, C>, BiConsumer<T, SubscriptionWithContext<C>>, BiConsumer<Throwable, C>, Consumer<C>) - Static method in class reactor.core.reactivestreams.SubscriberFactory
Create a Subscriber reacting onNext, onSubscribe, onError, onComplete with the passed BiConsumer.
create(Subscriber<? super T>, C) - Static method in class reactor.core.reactivestreams.SubscriberWithContext
Attach a given arbitrary context (stateful information) to a Subscriber, all Subscriber methods will delegate properly.
create(Subscription, C) - Static method in class reactor.core.reactivestreams.SubscriptionWithContext
Attach a given arbitrary context (stateful information) to a Subscription, all Subscription methods will delegate properly.
create(Throwable) - Static method in exception reactor.core.support.ReactorFatalException
 
create() - Static method in class reactor.core.support.UUIDUtils
Create a new time-based UUID.
create(Closure) - Static method in class reactor.groovy.config.GroovyEnvironment
 
create(Environment) - Static method in class reactor.rx.broadcast.BehaviorBroadcaster
Build a Broadcaster, first broadcasting the most recent signal then ready to broadcast values with Broadcaster.onNext(Object), Broadcaster.onError(Throwable), ().
create(Dispatcher) - Static method in class reactor.rx.broadcast.BehaviorBroadcaster
Build a Broadcaster, first broadcasting the most recent signal then ready to broadcast values with Action.onNext(Object), Broadcaster.onError(Throwable), Broadcaster.onComplete().
create(Environment, Dispatcher) - Static method in class reactor.rx.broadcast.BehaviorBroadcaster
Build a Broadcaster, first broadcasting the most recent signal then ready to broadcast values with (Object), Broadcaster.onError(Throwable), Broadcaster.onComplete().
create() - Static method in class reactor.rx.broadcast.Broadcaster
Build a Broadcaster, ready to broadcast values with .Broadcaster#onNext(Object), Broadcaster.onError(Throwable), Broadcaster.onComplete().
create(Environment) - Static method in class reactor.rx.broadcast.Broadcaster
Build a Broadcaster, ready to broadcast values with Broadcaster.onNext(Object), Broadcaster.onError(Throwable), Broadcaster.onComplete().
create(Dispatcher) - Static method in class reactor.rx.broadcast.Broadcaster
Build a Broadcaster, ready to broadcast values with Action.onNext(Object), Broadcaster.onError(Throwable), Broadcaster.onComplete().
create(Environment, Dispatcher) - Static method in class reactor.rx.broadcast.Broadcaster
Build a Broadcaster, ready to broadcast values with (Object), Broadcaster.onError(Throwable), Broadcaster.onComplete().
create() - Static method in class reactor.rx.broadcast.SerializedBroadcaster
Build a Broadcaster, ready to broadcast values with .Broadcaster#onNext(Object), Broadcaster.onError(Throwable), Broadcaster.onComplete().
create(Environment) - Static method in class reactor.rx.broadcast.SerializedBroadcaster
Build a Broadcaster, ready to broadcast values, ready to broadcast values with Broadcaster.onNext(Object), Broadcaster.onError(Throwable), Broadcaster.onComplete().
create(Iterable<? extends T>) - Static method in class reactor.rx.stream.IterableStream
Create an Iterable Stream Publisher
create(MapStream.Operation) - Static method in class reactor.rx.stream.MapStream.Signal
 
create(MapStream.Operation, K) - Static method in class reactor.rx.stream.MapStream.Signal
 
create(MapStream.Operation, K, V) - Static method in class reactor.rx.stream.MapStream.Signal
 
create(MapStream.Operation, K, V, V) - Static method in class reactor.rx.stream.MapStream.Signal
 
create(long, long) - Static method in class reactor.rx.stream.RangeStream
Create a Range Stream Publisher
create(Publisher<T>) - Static method in class reactor.rx.Streams
Build a custom sequence Stream from the passed Publisher that will be subscribed on the first request from the new subscriber.
createClient(String, int) - Method in class reactor.io.net.impl.zmq.tcp.ZeroMQ
 
CREATED - Static variable in class reactor.io.net.http.model.Status
201 Created
createDispatcherFactory(String, int, int, Consumer<Throwable>, ProducerType, WaitStrategy) - Static method in class reactor.Environment
Create a RingBuffer pool that will clone up to generated dispatcher and return a different one on a round robin fashion each time Supplier.get() is called.
createFanInSubscription() - Method in class reactor.rx.action.combination.CombineLatestAction
 
createFanInSubscription() - Method in class reactor.rx.action.combination.FanInAction
 
createFanInSubscription() - Method in class reactor.rx.action.combination.ZipAction
 
createInputStream(InputStream) - Method in class reactor.io.codec.compress.CompressionCodec
 
createInputStream(InputStream) - Method in class reactor.io.codec.compress.GzipCodec
 
createInputStream(InputStream) - Method in class reactor.io.codec.compress.SnappyCodec
 
createOutputStream(OutputStream) - Method in class reactor.io.codec.compress.CompressionCodec
 
createOutputStream(OutputStream) - Method in class reactor.io.codec.compress.GzipCodec
 
createOutputStream(OutputStream) - Method in class reactor.io.codec.compress.SnappyCodec
 
createServer(String, int) - Method in class reactor.io.net.impl.zmq.tcp.ZeroMQ
 
createSubscriber() - Method in class reactor.rx.action.combination.CombineLatestAction
 
createSubscriber() - Method in class reactor.rx.action.combination.FanInAction
 
createSubscriber() - Method in class reactor.rx.action.combination.MergeAction
 
createSubscriber() - Method in class reactor.rx.action.combination.ZipAction
 
createSubscription(Subscriber<? super O>, boolean) - Method in class reactor.rx.action.Action
 
createSubscription(Subscriber<? super O>, CompletableQueue<O>) - Method in class reactor.rx.action.Action
 
createSubscription(Subscriber<? super T>, CompletableQueue<T>) - Method in class reactor.rx.action.aggregation.CacheAction
 
createSubscription(Subscriber<? super O>, boolean) - Method in class reactor.rx.action.combination.DynamicMergeAction
 
createSubscription(Subscriber<? super O>, boolean) - Method in class reactor.rx.action.control.FlowControlAction
 
createSubscription(Subscriber<? super Void>, boolean) - Method in class reactor.rx.action.terminal.AdaptiveConsumerAction
 
createSubscription(Subscriber<? super Void>, boolean) - Method in class reactor.rx.action.terminal.ConsumerAction
 
createSubscription(Subscriber<? super O>, CompletableQueue<O>) - Method in class reactor.rx.broadcast.BehaviorBroadcaster
 
createSubscription(Subscriber<? super O>, CompletableQueue<O>) - Method in class reactor.rx.broadcast.Broadcaster
 
createSubscription(Subscriber<? super O>, boolean) - Method in class reactor.rx.broadcast.Broadcaster
 
createTrackingSubscription(Subscription) - Method in class reactor.rx.action.Action
 
createTrackingSubscription(Subscription) - Method in class reactor.rx.action.aggregation.BatchAction
 
createTrackingSubscription(Subscription) - Method in class reactor.rx.action.aggregation.BufferShiftAction
 
createTrackingSubscription(Subscription) - Method in class reactor.rx.action.combination.CombineLatestAction
 
createTrackingSubscription(Subscription) - Method in class reactor.rx.action.combination.ZipAction
 
createView() - Method in class reactor.io.buffer.Buffer
Create a Buffer.View of the current range of this Buffer.
createView(int, int) - Method in class reactor.io.buffer.Buffer
Create a Buffer.View of the given range of this Buffer.
createWindowStream() - Method in class reactor.rx.action.aggregation.WindowAction
 
createWindowStream() - Method in class reactor.rx.action.aggregation.WindowShiftAction
 
createWindowStream(T) - Method in class reactor.rx.action.aggregation.WindowShiftWhenAction
 
createWindowStream(T) - Method in class reactor.rx.action.aggregation.WindowWhenAction
 
createWith(BiConsumer<Long, SubscriberWithContext<T, Void>>) - Static method in class reactor.rx.Streams
Create a Stream reacting on requests with the passed BiConsumer
createWith(BiConsumer<Long, SubscriberWithContext<T, C>>, Function<Subscriber<? super T>, C>) - Static method in class reactor.rx.Streams
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.
createWith(BiConsumer<Long, SubscriberWithContext<T, C>>, Function<Subscriber<? super T>, C>, Consumer<C>) - Static method in class reactor.rx.Streams
Create a Stream reacting on requests with the passed BiConsumer.
current() - Method in class reactor.core.dispatch.wait.AgileWaitingStrategy
 
currentNextSignals - Variable in class reactor.rx.subscription.ReactiveSubscription
 
currentNextSignals() - Method in class reactor.rx.subscription.ReactiveSubscription
 
currentWindow() - Method in class reactor.rx.action.aggregation.WindowAction
 
currentWindow() - Method in class reactor.rx.action.aggregation.WindowWhenAction
 

D

data - Variable in class reactor.core.dispatch.AbstractLifecycleDispatcher.Task
 
dataBlockSize(int) - Method in class reactor.io.queue.spec.PersistentQueueSpec
 
DatagramServer<IN,OUT> - Class in reactor.io.net.udp
 
DatagramServer(Environment, Dispatcher, InetSocketAddress, NetworkInterface, ServerSocketOptions, Codec<Buffer, IN, OUT>) - Constructor for class reactor.io.net.udp.DatagramServer
 
DATE - Static variable in interface reactor.io.net.http.model.Headers
The HTTP Date header field name.
date(Date) - Method in interface reactor.io.net.http.model.WritableHeaders
 
date(Date) - Method in class reactor.io.net.impl.netty.http.NettyHttpHeaders
 
date(Date) - Method in class reactor.io.net.impl.netty.http.NettyHttpResponseHeaders
 
dateHeader(String, Date) - Method in interface reactor.io.net.http.model.WritableHeaders
 
dateHeader(String, Iterable<Date>) - Method in interface reactor.io.net.http.model.WritableHeaders
 
dateHeader(String, Date) - Method in class reactor.io.net.impl.netty.http.NettyHttpHeaders
 
dateHeader(String, Iterable<Date>) - Method in class reactor.io.net.impl.netty.http.NettyHttpHeaders
 
dateHeader(String, Date) - Method in class reactor.io.net.impl.netty.http.NettyHttpResponseHeaders
 
dateHeader(String, Iterable<Date>) - Method in class reactor.io.net.impl.netty.http.NettyHttpResponseHeaders
 
dealer(String) - Method in class reactor.io.net.impl.zmq.tcp.ZeroMQ
 
debug() - Method in class reactor.rx.action.Action
Print a debugged form of the root action relative to this one.
debug() - Method in class reactor.rx.action.CompositeAction
 
debug() - Method in interface reactor.rx.action.Control
Parse the materialized upstream source to fetch a materialized map form which allows for graph-style printing.
debug() - Method in class reactor.rx.action.support.TapAndControls
 
debug() - Method in class reactor.rx.Promise
 
decode(Publisher<? extends SRC>, Codec<SRC, IN, ?>) - Static method in class reactor.groovy.ext.StreamExtensions
 
decode(Publisher<? extends Buffer>) - Method in class reactor.io.codec.BufferCodec
 
decode(Publisher<? extends SRC>) - Method in class reactor.io.codec.Codec
Provide the caller with a decoder to turn a source object into an instance of the input type.
decode(Buffer, CharsetDecoder) - Method in class reactor.io.codec.StringCodec
 
decode(Codec<SRC, IN, ?>, Publisher<? extends SRC>) - Static method in class reactor.rx.IOStreams
Use the given Codec to decode any SRC data published by the publisher reference.
decode(Codec<O, V, ?>) - Method in class reactor.rx.Stream
Transform a sequence of codec source elements into codec input elements through Codec.decode(Publisher)
decoder(Consumer<byte[]>) - Method in class reactor.io.codec.ByteArrayCodec
 
decoder() - Method in class reactor.io.codec.Codec
Provide the caller with a decoder to turn a source object into an instance of the input type.
decoder(Consumer<IN>) - Method in class reactor.io.codec.Codec
Provide the caller with a decoder to turn a source object into an instance of the input type.
decoder(Consumer<IN>) - Method in class reactor.io.codec.compress.CompressionCodec
 
decoder(Consumer<IN>) - Method in class reactor.io.codec.DelimitedCodec
 
decoder(Consumer<Frame>) - Method in class reactor.io.codec.FrameCodec
 
decoder(Consumer<T>) - Method in class reactor.io.codec.JavaSerializationCodec
 
decoder(Consumer<IN>) - Method in class reactor.io.codec.json.JsonCodec
 
decoder(Consumer<IN>) - Method in class reactor.io.codec.LengthFieldCodec
 
decoder(Consumer<SRC>) - Method in class reactor.io.codec.PassThroughCodec
 
decoder(Consumer<IN>) - Method in class reactor.io.codec.SerializationCodec
 
decoder(Consumer<String>) - Method in class reactor.io.codec.StringCodec
 
decoder(Consumer<SyslogMessage>) - Method in class reactor.io.net.codec.syslog.SyslogCodec
 
decrement() - Method in class reactor.fn.timer.HashWheelTimer.TimerPausable
Decrement an amount of runs Registration has to run until it's elapsed
decrementSubscribers() - Method in class reactor.core.processor.ReactorProcessor
 
decrementWip() - Method in class reactor.rx.action.combination.DynamicMergeAction
 
DEFAULT_BASE_PATH - Static variable in class reactor.io.queue.spec.PersistentQueueSpec
 
DEFAULT_BIND_ADDRESS - Static variable in class reactor.io.net.NetStreams
 
DEFAULT_BUFFER_SIZE - Static variable in class reactor.core.dispatch.AbstractLifecycleDispatcher
 
DEFAULT_DELIMITER - Static variable in class reactor.io.codec.Codec
 
DEFAULT_HTTP_CLIENT_TYPE - Static variable in class reactor.io.net.NetStreams
 
DEFAULT_HTTP_SERVER_TYPE - Static variable in class reactor.io.net.NetStreams
 
DEFAULT_INTERVAL - Static variable in class reactor.io.net.Spec.IncrementalBackoffReconnect
 
DEFAULT_MAX_ATTEMPTS - Static variable in class reactor.io.net.Spec.IncrementalBackoffReconnect
 
DEFAULT_MULTIPLIER - Static variable in class reactor.io.net.Spec.IncrementalBackoffReconnect
 
DEFAULT_PORT - Static variable in class reactor.io.net.NetStreams
 
DEFAULT_TCP_CLIENT_TYPE - Static variable in class reactor.io.net.NetStreams
 
DEFAULT_TCP_SERVER_TYPE - Static variable in class reactor.io.net.NetStreams
 
DEFAULT_UDP_SERVER_TYPE - Static variable in class reactor.io.net.NetStreams
 
DEFAULT_WHEEL_SIZE - Static variable in class reactor.fn.timer.HashWheelTimer
 
defaultDispatcher() - Method in class reactor.bus.spec.DispatcherComponentSpec
Configures the component to use the configured Environment's default dispatcher
defaultEventAllocator() - Static method in class reactor.alloc.EventAllocator
Default Event Allocator, uses ReferenceCountingAllocator for allocating and recycling events.
defaultIfEmpty(O) - Method in class reactor.rx.Stream
Create an operation that returns the passed value if the Stream has completed without any emitted signals.
DefaultIfEmptyAction<T> - Class in reactor.rx.action.transformation
 
DefaultIfEmptyAction(T) - Constructor for class reactor.rx.action.transformation.DefaultIfEmptyAction
 
DefaultSubscriber<O> - Class in reactor.rx.action.support
 
DefaultSubscriber() - Constructor for class reactor.rx.action.support.DefaultSubscriber
 
defer(Supplier<? extends Publisher<T>>) - Static method in class reactor.rx.Streams
Supply a Publisher everytime subscribe is called on the returned stream.
DeferredStream<T> - Class in reactor.rx.stream
A Publisher supplier that will call the passed supplier on each subscribe call.
DeferredStream(Supplier<? extends Publisher<T>>) - Constructor for class reactor.rx.stream.DeferredStream
 
delegate() - Method in class reactor.core.reactivestreams.SerializedSubscriber
 
delegate() - Method in class reactor.io.net.ChannelStream
 
delegate() - Method in class reactor.io.net.impl.netty.http.NettyHttpChannel
 
delegate() - Method in class reactor.io.net.impl.netty.http.NettyHttpHeaders
 
delegate() - Method in class reactor.io.net.impl.netty.http.NettyHttpResponseHeaders
 
delegate() - Method in class reactor.io.net.impl.netty.NettyChannelStream
 
delegate() - Method in class reactor.io.net.impl.zmq.ZeroMQChannelStream
 
delegate(ChannelStream<IN, OUT>) - Static method in class reactor.io.net.NetStreams
Utils to read the ChannelStream underlying channel
delegate(ChannelStream<IN, OUT>, Class<E>) - Static method in class reactor.io.net.NetStreams
 
delegateFirstAndRun(Object, Closure<T>) - Static method in class reactor.groovy.config.DSLUtils
 
delete(String, ReactorChannelHandler<IN, OUT, HttpChannel<IN, OUT>>) - Method in class reactor.io.net.http.HttpClient
HTTP DELETE the passed URL.
delete(String) - Method in class reactor.io.net.http.HttpClient
HTTP DELETE the passed URL.
delete(String, ReactorChannelHandler<IN, OUT, HttpChannel<IN, OUT>>) - Method in class reactor.io.net.http.HttpServer
Listen for HTTP DELETE on the passed path to be used as a routing condition.
DELETE - Static variable in class reactor.io.net.http.model.Method
 
delete(String) - Static method in class reactor.io.net.NetSelectors
deleteOnExit(boolean) - Method in class reactor.io.queue.spec.PersistentQueueSpec
 
deleteOnExit() - Method in class reactor.rx.stream.io.ChronicleStream
 
DELIMITED_STRING_CODEC - Static variable in class reactor.io.codec.StandardCodecs
DelimitedCodec<IN,OUT> - Class in reactor.io.codec
An implementation of Codec that decodes by splitting a Buffer into segments based on a delimiter and encodes by appending its delimiter to each piece of output.
DelimitedCodec(Codec<Buffer, IN, OUT>) - Constructor for class reactor.io.codec.DelimitedCodec
Create a line-feed-delimited codec, using the given Codec as a delegate.
DelimitedCodec(boolean, Codec<Buffer, IN, OUT>) - Constructor for class reactor.io.codec.DelimitedCodec
Create a line-feed-delimited codec, using the given Codec as a delegate.
DelimitedCodec(byte, boolean, Codec<Buffer, IN, OUT>) - Constructor for class reactor.io.codec.DelimitedCodec
Create a delimited codec using the given delimiter and using the given Codec as a delegate.
delimiter - Variable in class reactor.io.codec.Codec
 
DELIMITING_BUFFER - Static variable in class reactor.io.buffer.Buffer
A delimiting buffer is sent to BufferCodec and other components to signal the end of a sequence of Buffer.
dematerialize() - Method in class reactor.rx.Stream
Transform the incoming onSubscribe, onNext, onError and onComplete signals into Signal.
DematerializeAction<T> - Class in reactor.rx.action.transformation
 
DematerializeAction() - Constructor for class reactor.rx.action.transformation.DematerializeAction
 
deserializer(ObjectMapper, Class<IN>, Consumer<IN>) - Method in class reactor.io.codec.json.JacksonJsonCodec
 
deserializer(Kryo, Class<IN>, Consumer<IN>) - Method in class reactor.io.codec.kryo.KryoCodec
 
deserializer(KryoPool, Class<IN>, Consumer<IN>) - Method in class reactor.io.codec.kryo.KryoPoolCodec
 
deserializer(Map<Class<?>, Message>, Class<IN>, Consumer<IN>) - Method in class reactor.io.codec.protobuf.ProtobufCodec
 
deserializer(E, Class<IN>, Consumer<IN>) - Method in class reactor.io.codec.SerializationCodec
 
detachAndStopAllAppenders() - Method in class reactor.logback.AsyncAppender
 
detachAppender(Appender<ILoggingEvent>) - Method in class reactor.logback.AsyncAppender
 
detachAppender(String) - Method in class reactor.logback.AsyncAppender
 
determineInterval(int) - Method in class reactor.io.net.Spec.IncrementalBackoffReconnect
Determine the period in milliseconds between reconnection attempts.
dispatch(E, Consumer<E>, Consumer<Throwable>) - Method in class reactor.core.dispatch.AbstractLifecycleDispatcher
 
dispatch(E, Consumer<E>, Consumer<Throwable>) - Method in class reactor.core.dispatch.SynchronousDispatcher
 
dispatch(E, Consumer<E>, Consumer<Throwable>) - Method in class reactor.core.dispatch.TailRecurseDispatcher
 
dispatch(E, Consumer<E>, Consumer<Throwable>) - Method in class reactor.core.dispatch.TraceableDelegatingDispatcher
 
dispatch(E, Consumer<E>, Consumer<Throwable>) - Method in interface reactor.core.Dispatcher
Instruct the Dispatcher to dispatch the data.
dispatcher(Dispatcher) - Method in class reactor.bus.spec.DispatcherComponentSpec
Configures the component to use the given dispatcher
dispatcher(String) - Method in class reactor.bus.spec.DispatcherComponentSpec
Configures the component to the dispatcher in the configured Environment with the given dispatcherName
Dispatcher - Interface in reactor.core
A Dispatcher is used to Dispatcher.dispatch(Object, Consumer, Consumer) dispatch} data to Consumers.
dispatcher(String) - Static method in class reactor.Environment
Obtain a registred dispatcher.
dispatcher(String, Dispatcher) - Static method in class reactor.Environment
Register a dispatcher into the context environment.
dispatcher(String, Closure) - Method in class reactor.groovy.config.EnvironmentBuilder
 
dispatcher(String, Dispatcher) - Method in class reactor.groovy.config.EnvironmentBuilder
 
dispatcher(String) - Method in class reactor.groovy.config.GroovyEnvironment
 
dispatcher(String, Dispatcher) - Method in class reactor.groovy.config.GroovyEnvironment
 
dispatcher(String) - Method in class reactor.groovy.config.ReactorBuilder
 
dispatcher - Variable in class reactor.rx.action.aggregation.BatchAction
 
dispatcher - Variable in class reactor.rx.action.combination.FanInAction
 
dispatcher - Variable in class reactor.rx.broadcast.Broadcaster
 
DISPATCHER_GROUP - Static variable in class reactor.Environment
The name of the default ring buffer group dispatcher
DispatcherAction<T> - Class in reactor.rx.action.control
 
DispatcherAction(Dispatcher, Dispatcher) - Constructor for class reactor.rx.action.control.DispatcherAction
 
DispatcherComponentSpec<SPEC extends DispatcherComponentSpec<SPEC,TARGET>,TARGET> - Class in reactor.bus.spec
A generic environment-aware class for specifying components that need to be configured with an Environment and Dispatcher.
DispatcherComponentSpec() - Constructor for class reactor.bus.spec.DispatcherComponentSpec
 
DispatcherConfiguration - Class in reactor.core.config
An encapsulation of the configuration for a Dispatcher.
DispatcherConfiguration(String, DispatcherType, Integer, Integer) - Constructor for class reactor.core.config.DispatcherConfiguration
 
DispatcherConfigurationBuilder - Class in reactor.groovy.config
 
DispatcherConfigurationBuilder(String) - Constructor for class reactor.groovy.config.DispatcherConfigurationBuilder
 
dispatchErrorHandler(Consumer<Throwable>) - Method in class reactor.bus.spec.EventRoutingComponentSpec
Configures the component's error handler for any errors occurring during dispatch (e.g.
DispatcherSupplier - Interface in reactor.core
Deprecated.
DispatcherType - Enum in reactor.core.config
An enumeration of supported types of Dispatcher.
dispatchOn(Environment) - Method in class reactor.rx.Stream
Assign a new Environment and its default Dispatcher to the returned Stream.
dispatchOn(Dispatcher) - Method in class reactor.rx.Stream
Assign a new Dispatcher to the returned Stream.
dispatchOn(Environment, Dispatcher) - Method in class reactor.rx.Stream
Assign the a new Dispatcher and an Environment to the returned Stream.
distinct() - Method in class reactor.rx.Stream
Create a new Stream that filters in only unique values.
distinct(Function<? super O, ? extends V>) - Method in class reactor.rx.Stream
Create a new Stream that filters in only values having distinct keys computed by function
DistinctAction<T,V> - Class in reactor.rx.action.filter
 
DistinctAction(Function<? super T, ? extends V>) - Constructor for class reactor.rx.action.filter.DistinctAction
 
distinctUntilChanged() - Method in class reactor.rx.Stream
Create a new Stream that filters out consecutive equals values.
distinctUntilChanged(Function<? super O, ? extends V>) - Method in class reactor.rx.Stream
Create a new Stream that filters out consecutive values having equal keys computed by function
DistinctUntilChangedAction<T,V> - Class in reactor.rx.action.filter
 
DistinctUntilChangedAction(Function<? super T, ? extends V>) - Constructor for class reactor.rx.action.filter.DistinctUntilChangedAction
 
doAddHeader(String, String) - Method in class reactor.io.net.http.HttpChannel
 
doAddHeader(String, String) - Method in class reactor.io.net.impl.netty.http.NettyHttpChannel
 
doAddResponseHeader(String, String) - Method in class reactor.io.net.http.HttpChannel
 
doAddResponseHeader(String, String) - Method in class reactor.io.net.impl.netty.http.NettyHttpChannel
 
doAppend(ILoggingEvent) - Method in class reactor.logback.AsyncAppender
 
doBufferDecode(Buffer) - Method in class reactor.io.codec.Codec
Decode a buffer
doBufferDecode(Buffer) - Method in class reactor.io.codec.json.JsonCodec
 
doBufferDecode(Buffer) - Method in class reactor.io.codec.StringCodec
 
doCancel() - Method in class reactor.core.reactivestreams.SubscriberBarrier
 
doComplete() - Method in class reactor.core.reactivestreams.SubscriberBarrier
 
doComplete() - Method in class reactor.rx.action.Action
 
doComplete() - Method in class reactor.rx.action.aggregation.BatchAction
 
doComplete() - Method in class reactor.rx.action.aggregation.BufferShiftAction
 
doComplete() - Method in class reactor.rx.action.aggregation.BufferShiftWhenAction
 
doComplete() - Method in class reactor.rx.action.aggregation.BufferWhenAction
 
doComplete() - Method in class reactor.rx.action.aggregation.CacheAction
 
doComplete() - Method in class reactor.rx.action.aggregation.LastAction
 
doComplete() - Method in class reactor.rx.action.aggregation.WindowAction
 
doComplete() - Method in class reactor.rx.action.aggregation.WindowShiftAction
 
doComplete() - Method in class reactor.rx.action.aggregation.WindowShiftWhenAction
 
doComplete() - Method in class reactor.rx.action.aggregation.WindowWhenAction
 
doComplete() - Method in class reactor.rx.action.combination.CombineLatestAction
 
doComplete() - Method in class reactor.rx.action.combination.SwitchAction
 
doComplete() - Method in class reactor.rx.action.combination.ZipAction
 
doComplete() - Method in class reactor.rx.action.conditional.ExistsAction
 
doComplete() - Method in class reactor.rx.action.control.RepeatWhenAction
 
doComplete() - Method in class reactor.rx.action.error.RetryWhenAction
 
doComplete() - Method in class reactor.rx.action.filter.DistinctAction
 
doComplete() - Method in class reactor.rx.action.filter.ElementAtAction
 
doComplete() - Method in class reactor.rx.action.metrics.CountAction
 
doComplete() - Method in class reactor.rx.action.pair.ReduceByKeyAction
 
doComplete() - Method in class reactor.rx.action.passive.AfterAction
 
doComplete() - Method in class reactor.rx.action.passive.CallbackAction
 
doComplete() - Method in class reactor.rx.action.passive.FinallyAction
 
doComplete() - Method in class reactor.rx.action.passive.LoggerAction
 
doComplete() - Method in class reactor.rx.action.terminal.ConsumerAction
 
doComplete() - Method in class reactor.rx.action.transformation.DefaultIfEmptyAction
 
doComplete() - Method in class reactor.rx.action.transformation.GroupByAction
 
doComplete() - Method in class reactor.rx.action.transformation.MaterializeAction
 
doComplete() - Method in class reactor.rx.action.transformation.ScanAction
 
doComplete() - Method in class reactor.rx.broadcast.BehaviorBroadcaster
 
doDecoded(IN) - Method in class reactor.io.net.ChannelStream
 
doDecoded(IN) - Method in class reactor.io.net.impl.netty.http.NettyHttpChannel
 
doDecoded(IN) - Method in class reactor.io.net.impl.netty.NettyChannelStream
 
doDecoded(IN) - Method in class reactor.io.net.impl.zmq.ZeroMQChannelStream
 
doDelimitedBufferDecode(Consumer<IN>, Buffer) - Method in class reactor.io.codec.Codec
Helper method to scan for delimiting byte the codec might benefit from, e.g.
doError(Throwable) - Method in class reactor.core.reactivestreams.SubscriberBarrier
 
doError(Throwable) - Method in class reactor.rx.action.Action
 
doError(Throwable) - Method in class reactor.rx.action.aggregation.BufferAction
 
doError(Throwable) - Method in class reactor.rx.action.aggregation.BufferShiftAction
 
doError(Throwable) - Method in class reactor.rx.action.aggregation.BufferShiftWhenAction
 
doError(Throwable) - Method in class reactor.rx.action.aggregation.BufferWhenAction
 
doError(Throwable) - Method in class reactor.rx.action.aggregation.CacheAction
 
doError(Throwable) - Method in class reactor.rx.action.aggregation.WindowAction
 
doError(Throwable) - Method in class reactor.rx.action.aggregation.WindowShiftAction
 
doError(Throwable) - Method in class reactor.rx.action.aggregation.WindowShiftWhenAction
 
doError(Throwable) - Method in class reactor.rx.action.aggregation.WindowWhenAction
 
doError(Throwable) - Method in class reactor.rx.action.error.ErrorAction
 
doError(Throwable) - Method in class reactor.rx.action.error.ErrorReturnAction
 
doError(Throwable) - Method in class reactor.rx.action.error.ErrorWithValueAction
 
doError(Throwable) - Method in class reactor.rx.action.error.IgnoreErrorAction
 
doError(Throwable) - Method in class reactor.rx.action.passive.AfterAction
 
doError(Throwable) - Method in class reactor.rx.action.passive.FinallyAction
 
doError(Throwable) - Method in class reactor.rx.action.passive.LoggerAction
 
doError(Throwable) - Method in class reactor.rx.action.terminal.AdaptiveConsumerAction
 
doError(Throwable) - Method in class reactor.rx.action.terminal.ConsumerAction
 
doError(Throwable) - Method in class reactor.rx.action.transformation.MaterializeAction
 
doError(Throwable) - Method in class reactor.rx.broadcast.BehaviorBroadcaster
 
doFallbackNext(T) - Method in class reactor.rx.action.error.FallbackAction
 
doFilter(List<T>, Object) - Method in class reactor.bus.filter.FirstFilter
 
doFilter(List<T>, Object) - Method in class reactor.bus.filter.PassThroughFilter
 
doFilter(List<T>, Object) - Method in class reactor.bus.filter.RandomFilter
 
doFilter(List<T>, Object) - Method in class reactor.bus.filter.RoundRobinFilter
 
doHeader(String, String) - Method in class reactor.io.net.http.HttpChannel
 
doHeader(String, String) - Method in class reactor.io.net.impl.netty.http.NettyHttpChannel
 
doNext(I) - Method in class reactor.core.reactivestreams.SubscriberBarrier
 
doNext(I) - Method in class reactor.rx.action.Action
 
doNext(T) - Method in class reactor.rx.action.aggregation.BatchAction
 
doNext(T) - Method in class reactor.rx.action.aggregation.BufferShiftAction
 
doNext(T) - Method in class reactor.rx.action.aggregation.BufferShiftWhenAction
 
doNext(T) - Method in class reactor.rx.action.aggregation.BufferWhenAction
 
doNext(T) - Method in class reactor.rx.action.aggregation.CacheAction
 
doNext(T) - Method in class reactor.rx.action.aggregation.LastAction
 
doNext(T) - Method in class reactor.rx.action.aggregation.WindowShiftAction
 
doNext(T) - Method in class reactor.rx.action.aggregation.WindowShiftWhenAction
 
doNext(T) - Method in class reactor.rx.action.aggregation.WindowWhenAction
 
doNext(CombineLatestAction.Zippable<O>) - Method in class reactor.rx.action.combination.CombineLatestAction
 
doNext(Publisher<? extends T>) - Method in class reactor.rx.action.combination.ConcatAction
 
doNext(Publisher<? extends I>) - Method in class reactor.rx.action.combination.DynamicMergeAction
 
doNext(O) - Method in class reactor.rx.action.combination.MergeAction
 
doNext(Publisher<? extends T>) - Method in class reactor.rx.action.combination.SwitchAction
 
doNext(ZipAction.Zippable<O>) - Method in class reactor.rx.action.combination.ZipAction
 
doNext(E) - Method in class reactor.rx.action.CompositeAction
 
doNext(T) - Method in class reactor.rx.action.conditional.ExistsAction
 
doNext(T) - Method in class reactor.rx.action.control.DispatcherAction
 
doNext(O) - Method in class reactor.rx.action.control.FlowControlAction
 
doNext(T) - Method in class reactor.rx.action.control.RepeatAction
 
doNext(T) - Method in class reactor.rx.action.control.RepeatWhenAction
 
doNext(T) - Method in class reactor.rx.action.control.ThrottleRequestAction
 
doNext(T) - Method in class reactor.rx.action.control.ThrottleRequestWhenAction
 
doNext(T) - Method in class reactor.rx.action.error.ErrorReturnAction
 
doNext(T) - Method in class reactor.rx.action.error.FallbackAction
 
doNext(T) - Method in class reactor.rx.action.error.IgnoreErrorAction
 
doNext(T) - Method in class reactor.rx.action.error.RetryAction
 
doNext(T) - Method in class reactor.rx.action.error.RetryWhenAction
 
doNext(T) - Method in class reactor.rx.action.filter.DistinctAction
 
doNext(T) - Method in class reactor.rx.action.filter.DistinctUntilChangedAction
 
doNext(T) - Method in class reactor.rx.action.filter.ElementAtAction
 
doNext(T) - Method in class reactor.rx.action.filter.FilterAction
 
doNext(T) - Method in class reactor.rx.action.filter.SkipAction
 
doNext(T) - Method in class reactor.rx.action.filter.SkipUntilTimeout
 
doNext(T) - Method in class reactor.rx.action.filter.TakeAction
 
doNext(T) - Method in class reactor.rx.action.filter.TakeUntilTimeout
 
doNext(T) - Method in class reactor.rx.action.filter.TakeWhileAction
 
doNext(T) - Method in class reactor.rx.action.metrics.CountAction
 
doNext(T) - Method in class reactor.rx.action.metrics.ElapsedAction
 
doNext(T) - Method in class reactor.rx.action.metrics.TimestampAction
 
doNext(PushSubscription<Tuple2<K, V>>, Tuple2<K, V>) - Method in class reactor.rx.action.pair.ReduceByKeyAction
 
doNext(Tuple2<K, V>) - Method in class reactor.rx.action.pair.ScanByKeyAction
 
doNext(PushSubscription<Tuple2<K, V>>, Tuple2<K, V>) - Method in class reactor.rx.action.pair.ScanByKeyAction
 
doNext(T) - Method in class reactor.rx.action.passive.AfterAction
 
doNext(T) - Method in class reactor.rx.action.passive.CallbackAction
 
doNext(T) - Method in class reactor.rx.action.passive.FinallyAction
 
doNext(T) - Method in class reactor.rx.action.passive.LoggerAction
 
doNext(T) - Method in class reactor.rx.action.passive.StreamStateCallbackAction
 
doNext(T) - Method in class reactor.rx.action.terminal.AdaptiveConsumerAction
 
doNext(T) - Method in class reactor.rx.action.terminal.ConsumerAction
 
doNext(T) - Method in class reactor.rx.action.transformation.DefaultIfEmptyAction
 
doNext(Signal<T>) - Method in class reactor.rx.action.transformation.DematerializeAction
 
doNext(T) - Method in class reactor.rx.action.transformation.GroupByAction
 
doNext(T) - Method in class reactor.rx.action.transformation.MapAction
 
doNext(T) - Method in class reactor.rx.action.transformation.MaterializeAction
 
doNext(T) - Method in class reactor.rx.action.transformation.ScanAction
 
doNext(Iterable<? extends T>) - Method in class reactor.rx.action.transformation.SplitAction
 
doNext(O) - Method in class reactor.rx.broadcast.Broadcaster
 
doNormalNext(T) - Method in class reactor.rx.action.error.ErrorAction
 
doNormalNext(T) - Method in class reactor.rx.action.error.ErrorWithValueAction
 
doNormalNext(T) - Method in class reactor.rx.action.error.FallbackAction
 
doNormalNext(T) - Method in class reactor.rx.action.error.TimeoutAction
 
doOnSubscribe(ChannelHandlerContext, Subscription) - Method in class reactor.io.net.impl.netty.http.NettyHttpServerHandler
 
doOnSubscribe(ChannelHandlerContext, Subscription) - Method in class reactor.io.net.impl.netty.NettyChannelHandlerBridge
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.Action
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.aggregation.BufferShiftAction
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.aggregation.BufferShiftWhenAction
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.aggregation.BufferWhenAction
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.aggregation.WindowShiftAction
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.aggregation.WindowShiftWhenAction
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.aggregation.WindowWhenAction
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.combination.ConcatAction
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.combination.FanInAction
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.combination.ZipAction
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.control.DispatcherAction
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.control.RepeatAction
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.control.RepeatWhenAction
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.error.RetryAction
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.filter.SkipUntilTimeout
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.filter.TakeUntilTimeout
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.metrics.ElapsedAction
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.passive.LoggerAction
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.passive.StreamStateCallbackAction
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.terminal.AdaptiveConsumerAction
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.terminal.ConsumerAction
 
doOnTerminate(ChannelHandlerContext, ChannelFuture, ChannelPromise) - Method in class reactor.io.net.impl.netty.http.NettyHttpClientHandler
 
doOnTerminate(ChannelHandlerContext, ChannelFuture, ChannelPromise) - Method in class reactor.io.net.impl.netty.http.NettyHttpWSClientHandler
 
doOnTerminate(ChannelHandlerContext, ChannelFuture, ChannelPromise) - Method in class reactor.io.net.impl.netty.NettyChannelHandlerBridge
 
doOnWrite(Object, ChannelHandlerContext) - Method in class reactor.io.net.impl.netty.http.NettyHttpClientHandler
 
doOnWrite(Object, ChannelHandlerContext) - Method in class reactor.io.net.impl.netty.http.NettyHttpServerHandler
 
doOnWrite(Object, ChannelHandlerContext) - Method in class reactor.io.net.impl.netty.http.NettyHttpWSClientHandler
 
doOnWrite(Object, ChannelHandlerContext) - Method in class reactor.io.net.impl.netty.http.NettyHttpWSServerHandler
 
doOnWrite(Object, ChannelHandlerContext) - Method in class reactor.io.net.impl.netty.NettyChannelHandlerBridge
 
doRead(ChannelHandlerContext, Object) - Method in class reactor.io.net.impl.netty.NettyChannelHandlerBridge
 
doRequest(long) - Method in class reactor.core.reactivestreams.SubscriberBarrier
 
doRequest(long) - Method in class reactor.rx.action.control.ThrottleRequestWhenAction
 
doResponseHeader(String, String) - Method in class reactor.io.net.http.HttpChannel
 
doResponseHeader(String, String) - Method in class reactor.io.net.impl.netty.http.NettyHttpChannel
 
doResponseStatus(Status) - Method in class reactor.io.net.http.HttpChannel
 
doResponseStatus(Status) - Method in class reactor.io.net.impl.netty.http.NettyHttpChannel
 
doRetry() - Method in class reactor.rx.action.control.RepeatWhenAction
 
doRetry() - Method in class reactor.rx.action.error.RetryWhenAction
 
doShutdown() - Method in class reactor.io.net.impl.netty.http.NettyHttpClient
 
doShutdown() - Method in class reactor.io.net.impl.netty.http.NettyHttpServer
 
doShutdown() - Method in class reactor.io.net.impl.netty.tcp.NettyTcpClient
 
doShutdown() - Method in class reactor.io.net.impl.netty.tcp.NettyTcpServer
 
doShutdown() - Method in class reactor.io.net.impl.netty.udp.NettyDatagramServer
 
doShutdown() - Method in class reactor.io.net.impl.zmq.tcp.ZeroMQTcpClient
 
doShutdown() - Method in class reactor.io.net.impl.zmq.tcp.ZeroMQTcpServer
 
doShutdown() - Method in class reactor.io.net.ReactorPeer
 
doShutdown() - Method in class reactor.rx.action.Action
 
doShutdown() - Method in class reactor.rx.action.combination.SwitchAction
 
doShutdown() - Method in class reactor.rx.action.control.ThrottleRequestAction
 
doShutdown() - Method in class reactor.rx.action.error.TimeoutAction
 
doShutdown() - Method in class reactor.rx.action.passive.StreamStateCallbackAction
 
doShutdown() - Method in class reactor.rx.action.terminal.AdaptiveConsumerAction
 
doStart(ReactorChannelHandler<IN, OUT, HttpChannel<IN, OUT>>) - Method in class reactor.io.net.impl.netty.http.NettyHttpClient
 
doStart(ReactorChannelHandler<IN, OUT, HttpChannel<IN, OUT>>, Reconnect) - Method in class reactor.io.net.impl.netty.http.NettyHttpClient
 
doStart(ReactorChannelHandler<IN, OUT, HttpChannel<IN, OUT>>) - Method in class reactor.io.net.impl.netty.http.NettyHttpServer
 
doStart(ReactorChannelHandler<IN, OUT, ChannelStream<IN, OUT>>) - Method in class reactor.io.net.impl.netty.tcp.NettyTcpClient
 
doStart(ReactorChannelHandler<IN, OUT, ChannelStream<IN, OUT>>, Reconnect) - Method in class reactor.io.net.impl.netty.tcp.NettyTcpClient
 
doStart(ReactorChannelHandler<IN, OUT, ChannelStream<IN, OUT>>) - Method in class reactor.io.net.impl.netty.tcp.NettyTcpServer
 
doStart(ReactorChannelHandler<IN, OUT, ChannelStream<IN, OUT>>) - Method in class reactor.io.net.impl.netty.udp.NettyDatagramServer
 
doStart(ReactorChannelHandler, Reconnect) - Method in class reactor.io.net.impl.zmq.tcp.ZeroMQTcpClient
 
doStart(ReactorChannelHandler<IN, OUT, ChannelStream<IN, OUT>>) - Method in class reactor.io.net.impl.zmq.tcp.ZeroMQTcpClient
 
doStart(ReactorChannelHandler<IN, OUT, ChannelStream<IN, OUT>>) - Method in class reactor.io.net.impl.zmq.tcp.ZeroMQTcpServer
 
doStart(ReactorChannelHandler<IN, OUT, CONN>, Reconnect) - Method in class reactor.io.net.ReactorClient
 
doStart(ReactorChannelHandler<IN, OUT, CONN>) - Method in class reactor.io.net.ReactorPeer
 
doStart() - Method in class reactor.logback.AsyncAppender
 
doStart() - Method in class reactor.logback.DurableAsyncAppender
 
doStart() - Method in class reactor.rx.action.Action
 
doStop() - Method in class reactor.logback.AsyncAppender
 
doStop() - Method in class reactor.logback.DurableAsyncAppender
 
doSubscribe(Subscription) - Method in class reactor.core.reactivestreams.SubscriberBarrier
 
doSubscribeWriter(Publisher<? extends OUT>, Subscriber<? super Void>) - Method in class reactor.io.net.ChannelStream
 
doSubscribeWriter(Publisher<? extends OUT>, Subscriber<? super Void>) - Method in class reactor.io.net.impl.netty.http.NettyHttpChannel
 
doSubscribeWriter(Publisher<? extends OUT>, Subscriber<? super Void>) - Method in class reactor.io.net.impl.netty.NettyChannelStream
 
doSubscribeWriter(Publisher<? extends OUT>, Subscriber<? super Void>) - Method in class reactor.io.net.impl.zmq.ZeroMQChannelStream
 
doSwitch() - Method in class reactor.rx.action.error.FallbackAction
 
doubleValue() - Method in class reactor.alloc.RecyclableNumber
 
doWithReactor(Closure) - Method in class reactor.groovy.config.ReactorScriptWrapper
 
downstreamSubscription - Variable in class reactor.rx.action.Action
 
downstreamSubscription() - Method in class reactor.rx.action.Action
Get the current action child subscription
downstreamSubscription() - Method in class reactor.rx.Stream
Get the current action child subscription
drain(Iterable<T>) - Static method in class reactor.fn.Suppliers
Deprecated.
Create a Supplier which drains the contents of the given Iterable by internally creating an Iterator and delegating each call of Supplier.get() to Iterator.next().
drainAll(Iterable<Iterable<T>>) - Static method in class reactor.fn.Suppliers
Deprecated.
Create a Supplier which drains all of the given Iterables.
draining - Variable in class reactor.rx.subscription.ReactiveSubscription
 
DropSubscription<O> - Class in reactor.rx.subscription
Relationship between a Stream (Publisher) and a Subscriber.
DropSubscription(Stream<O>, Subscriber<? super O>) - Constructor for class reactor.rx.subscription.DropSubscription
 
DSLUtils - Class in reactor.groovy.config
 
DSLUtils() - Constructor for class reactor.groovy.config.DSLUtils
 
duplicate() - Method in class reactor.io.buffer.Buffer
Create a new Buffer by calling ByteBuffer.duplicate() on the underlying ByteBuffer.
DurableAsyncAppender - Class in reactor.logback
An AsyncAppender subclass that first writes a log event to a durable Chronicle using Java Chronicle before allowing the event to be queued.
DurableAsyncAppender() - Constructor for class reactor.logback.DurableAsyncAppender
 
DurableLogUtility - Class in reactor.logback
 
DurableLogUtility() - Constructor for class reactor.logback.DurableLogUtility
 
DynamicMergeAction<I,O> - Class in reactor.rx.action.combination
 
DynamicMergeAction(FanInAction<I, ?, O, ? extends FanInAction.InnerSubscriber<I, ?, O>>) - Constructor for class reactor.rx.action.combination.DynamicMergeAction
 
dynamicMergeAction() - Method in class reactor.rx.action.combination.FanInAction
 

E

elapsed() - Method in class reactor.rx.Stream
Create a new Stream that accepts a Tuple2 of T1 Long timemillis and T2 associated data.
ElapsedAction<T> - Class in reactor.rx.action.metrics
 
ElapsedAction() - Constructor for class reactor.rx.action.metrics.ElapsedAction
 
element() - Method in class reactor.core.queue.internal.MpscLinkedQueue
 
elementAt(int) - Method in class reactor.rx.Stream
Create a new Stream that emits an item at a specified index from a source Stream
ElementAtAction<T> - Class in reactor.rx.action.filter
 
ElementAtAction(int) - Constructor for class reactor.rx.action.filter.ElementAtAction
 
ElementAtAction(int, T) - Constructor for class reactor.rx.action.filter.ElementAtAction
 
ElementAtAction(int, T, boolean) - Constructor for class reactor.rx.action.filter.ElementAtAction
 
elementAtOrDefault(int, O) - Method in class reactor.rx.Stream
Create a new Stream that emits an item at a specified index from a source Stream or default value when index is out of bounds
empty() - Static method in class reactor.fn.tuple.Tuple
Create a Tuple1 with the given object.
EMPTY - Static variable in class reactor.rx.stream.SingleValueStream
 
empty() - Static method in class reactor.rx.Streams
Build a Stream that will only emit a complete signal to any new subscriber.
EMPTY_CLOSURE - Static variable in class reactor.groovy.config.DSLUtils
 
encode(Publisher<? extends OUT>) - Method in class reactor.io.codec.BufferCodec
 
encode(Publisher<? extends OUT>) - Method in class reactor.io.codec.Codec
Provide the caller with an encoder to turn an output sequence into an sequence of the source type.
encode(String, CharsetEncoder) - Method in class reactor.io.codec.StringCodec
 
encode(Codec<V, ?, O>) - Method in class reactor.rx.Stream
Transform a sequence of codec output elements into codec source elements through Codec.encode(Publisher)
encoder() - Method in class reactor.io.codec.Codec
Provide the caller with an encoder to turn an output object into an instance of the source type.
encoder() - Method in class reactor.io.codec.StringCodec
 
entries - Variable in class reactor.fn.tuple.TupleN
 
entries() - Method in interface reactor.io.net.http.model.ReadableHeaders
 
entries() - Method in class reactor.io.net.impl.netty.http.NettyHttpHeaders
 
entries() - Method in class reactor.io.net.impl.netty.http.NettyHttpResponseHeaders
 
entrySet() - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
env(Environment) - Method in class reactor.bus.spec.DispatcherComponentSpec
Configures the spec, and potentially the component being configured, to use the given environment
env(Environment) - Method in class reactor.rx.Stream
Assign an Environment to be provided to this Stream Subscribers
Environment - Class in reactor
 
Environment() - Constructor for class reactor.Environment
Creates a new Environment that will use a PropertiesConfigurationReader to obtain its initial configuration.
Environment(ConfigurationReader) - Constructor for class reactor.Environment
Creates a new Environment that will use the given configurationReader to obtain its initial configuration.
Environment(Map<String, Dispatcher>, ConfigurationReader) - Constructor for class reactor.Environment
Creates a new Environment that will contain the given dispatchers, will use the given configurationReader to obtain additional configuration.
environment(Closure) - Method in class reactor.groovy.config.GroovyEnvironment
 
environment(Map, Closure) - Method in class reactor.groovy.config.GroovyEnvironment
 
environment(Environment) - Method in class reactor.groovy.config.GroovyEnvironment
 
environment() - Method in class reactor.groovy.config.GroovyEnvironment
 
environment - Variable in class reactor.rx.broadcast.Broadcaster
 
EnvironmentBuilder - Class in reactor.groovy.config
 
EnvironmentBuilder(Properties) - Constructor for class reactor.groovy.config.EnvironmentBuilder
 
equals(Object) - Method in class reactor.fn.tuple.Tuple
 
equals(Object) - Method in class reactor.fn.tuple.Tuple1
 
equals(Object) - Method in class reactor.fn.tuple.Tuple2
 
equals(Object) - Method in class reactor.fn.tuple.Tuple3
 
equals(Object) - Method in class reactor.fn.tuple.Tuple4
 
equals(Object) - Method in class reactor.fn.tuple.Tuple5
 
equals(Object) - Method in class reactor.fn.tuple.Tuple6
 
equals(Object) - Method in class reactor.fn.tuple.Tuple7
 
equals(Object) - Method in class reactor.fn.tuple.Tuple8
 
equals(Object) - Method in class reactor.fn.tuple.TupleN
 
equals(Object) - Method in class reactor.io.net.http.model.Method
 
equals(Object) - Method in class reactor.io.net.http.model.Status
Equality of Status only depends on Status.code.
equals(Object) - Method in class reactor.rx.action.Signal
 
equals(Object) - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
equals(Object) - Method in class reactor.rx.subscription.PushSubscription
 
equals(Object) - Method in class reactor.rx.subscription.support.WrappedSubscription
 
error - Variable in class reactor.core.processor.MutableSignal
 
error(Throwable) - Static method in class reactor.rx.action.Signal
Creates and returns a Signal of variety Type.ERROR, and assigns it an exception.
error(Throwable) - Static method in class reactor.rx.Promises
Create synchronous Promise and use the given error to complete the Promise immediately.
error(Environment, Throwable) - Static method in class reactor.rx.Promises
Create a Promise and use the given error to complete the Promise immediately.
error(Environment, Dispatcher, Throwable) - Static method in class reactor.rx.Promises
Create a Promise and use the given error to complete the Promise immediately.
errorAccepted(Throwable) - Method in class reactor.rx.Promise
 
ErrorAction<T,E extends Throwable> - Class in reactor.rx.action.error
 
ErrorAction(Class<E>, Consumer<? super E>, Publisher<? extends T>) - Constructor for class reactor.rx.action.error.ErrorAction
 
errorConsumer - Variable in class reactor.core.dispatch.AbstractLifecycleDispatcher.Task
 
ErrorReturnAction<T,E extends Throwable> - Class in reactor.rx.action.error
 
ErrorReturnAction(Class<E>, Function<? super E, ? extends T>) - Constructor for class reactor.rx.action.error.ErrorReturnAction
 
ErrorStream<O,T extends Throwable> - Class in reactor.rx.stream
A Stream that emits a sigle error signal.
ErrorStream(T) - Constructor for class reactor.rx.stream.ErrorStream
 
ErrorWithValueAction<T,E extends Throwable> - Class in reactor.rx.action.error
 
ErrorWithValueAction(Class<E>, BiConsumer<Object, ? super E>, Publisher<? extends T>) - Constructor for class reactor.rx.action.error.ErrorWithValueAction
 
ETAG - Static variable in interface reactor.io.net.http.model.ResponseHeaders
The HTTP ETag header field name.
evaluateCapacity(long) - Static method in class reactor.rx.action.Action
 
Event<T> - Class in reactor.bus
Wrapper for an object that needs to be processed by Consumers.
Event(Class<T>) - Constructor for class reactor.bus.Event
Creates a new Event based on the type T of
Event(Event.Headers, T) - Constructor for class reactor.bus.Event
Creates a new Event with the given headers and data.
Event(Event.Headers, T, Consumer<Throwable>) - Constructor for class reactor.bus.Event
Creates a new Event with the given headers, data and .
Event(T) - Constructor for class reactor.bus.Event
Creates a new Event with the given data.
Event.Headers - Class in reactor.bus
Headers are a Map-like structure of name-value pairs.
EventAllocator - Class in reactor.alloc
Generic Event Allocator.
EventAllocator() - Constructor for class reactor.alloc.EventAllocator
 
EventAllocator(Class[]) - Constructor for class reactor.alloc.EventAllocator
Create a new EventAllocator, containing pre-created Allocators for given es.
EventBus - Class in reactor.bus
A reactor is an event gateway that allows other components to register Event Consumers that can subsequently be notified of events.
EventBus(Dispatcher) - Constructor for class reactor.bus.EventBus
Create a new Reactor that uses the given Dispatcher.
EventBus(Dispatcher, Router) - Constructor for class reactor.bus.EventBus
Create a new Reactor that uses the given Dispatcher.
EventBus(Dispatcher, Router, Consumer<Throwable>, Consumer<Throwable>) - Constructor for class reactor.bus.EventBus
 
EventBus(Registry<Object, Consumer<? extends Event<?>>>, Dispatcher, Router, Consumer<Throwable>, Consumer<Throwable>) - Constructor for class reactor.bus.EventBus
Create a new Reactor that uses the given dispatacher and eventRouter.
EventBus.ReplyToConsumer<E extends Event<?>,V> - Class in reactor.bus
 
EventBus.ReplyToEvent<T> - Class in reactor.bus
 
EventBusSpec - Class in reactor.bus.spec
A helper class for configuring a new EventBus.
EventBusSpec() - Constructor for class reactor.bus.spec.EventBusSpec
 
EventConsumer<T> - Class in reactor.bus.support
Simple Consumer implementation that pulls the data from an Event and passes it to a delegate Consumer.
EventConsumer(Consumer<T>) - Constructor for class reactor.bus.support.EventConsumer
Creates a new EventConsumer that will pass event data to the given delegate.
eventConsumer - Variable in class reactor.core.dispatch.AbstractLifecycleDispatcher.Task
 
EventFactorySupplier<T> - Class in reactor.alloc
A Supplier implementation that instantiates Events based on Event data type.
EventFactorySupplier(Class<T>) - Constructor for class reactor.alloc.EventFactorySupplier
 
eventFilter(Filter) - Method in class reactor.bus.spec.EventRoutingComponentSpec
Assigns the component's Filter
eventLoopGroup() - Method in class reactor.io.net.impl.netty.NettyClientSocketOptions
 
eventLoopGroup(EventLoopGroup) - Method in class reactor.io.net.impl.netty.NettyClientSocketOptions
 
eventLoopGroup() - Method in class reactor.io.net.impl.netty.NettyServerSocketOptions
 
eventLoopGroup(EventLoopGroup) - Method in class reactor.io.net.impl.netty.NettyServerSocketOptions
 
eventRouter(Router) - Method in class reactor.bus.spec.EventRoutingComponentSpec
Assigns the component's EventRouter
EventRoutingComponentSpec<SPEC extends EventRoutingComponentSpec<SPEC,TARGET>,TARGET> - Class in reactor.bus.spec
A generic environment-aware class for specifying components that need to be configured with an Environment, Dispatcher, and Router.
EventRoutingComponentSpec() - Constructor for class reactor.bus.spec.EventRoutingComponentSpec
 
EventRoutingComponentSpec.EventRoutingStrategy - Enum in reactor.bus.spec
 
EventTimer - Class in reactor.bus.timer
A hashed wheel timer implementation that uses a Registry and custom Selectors to determine when tasks should be executed.
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class reactor.io.net.impl.netty.NettyChannelHandlerBridge
 
Exceptions - Class in reactor.core.support
Static Helpers to decorate an exception with an associated data Original design from https://github.com/ReactiveX/RxJava/blob/1.x/src/main/java/rx/exceptions/Exceptions.java
Exceptions() - Constructor for class reactor.core.support.Exceptions
 
Exceptions.ValueCause - Exception in reactor.core.support
Represents an exception that was encountered while trying to emit an item from an Observable, and tries to preserve that item for future use and/or reporting.
execute(Runnable) - Method in class reactor.core.dispatch.AbstractLifecycleDispatcher
 
execute(AbstractLifecycleDispatcher.Task) - Method in class reactor.core.dispatch.AbstractLifecycleDispatcher
 
execute(AbstractLifecycleDispatcher.Task) - Method in class reactor.core.dispatch.MpscDispatcher
 
execute(AbstractLifecycleDispatcher.Task) - Method in class reactor.core.dispatch.RingBufferDispatcher
 
execute(Runnable) - Method in class reactor.core.dispatch.SynchronousDispatcher
 
execute(Runnable) - Method in class reactor.core.dispatch.TailRecurseDispatcher
 
execute(AbstractLifecycleDispatcher.Task) - Method in class reactor.core.dispatch.ThreadPoolExecutorDispatcher
 
execute(Runnable) - Method in class reactor.core.dispatch.ThreadPoolExecutorDispatcher
 
execute(Runnable) - Method in class reactor.core.dispatch.TraceableDelegatingDispatcher
 
execute(AbstractLifecycleDispatcher.Task) - Method in class reactor.core.dispatch.WorkQueueDispatcher
 
execute(Runnable) - Method in class reactor.core.processor.util.SingleUseExecutor
 
executor - Variable in class reactor.core.processor.ExecutorPoweredProcessor
 
ExecutorPoweredProcessor<IN,OUT> - Class in reactor.core.processor
A base processor used by executor backed processors to take care of their ExecutorService
ExecutorPoweredProcessor(String, ExecutorService, boolean) - Constructor for class reactor.core.processor.ExecutorPoweredProcessor
 
exists(Predicate<? super O>) - Method in class reactor.rx.Stream
Create a new Stream that emits true when any value satisfies a predicate and false otherwise
ExistsAction<T> - Class in reactor.rx.action.conditional
 
ExistsAction(Predicate<? super T>) - Constructor for class reactor.rx.action.conditional.ExistsAction
 
expandTailRecursionPile(int) - Method in class reactor.core.dispatch.SingleThreadDispatcher
 
EXPECT - Static variable in interface reactor.io.net.http.model.HttpHeaders
The HTTP Expect header field name.
EXPECTATION_FAILED - Static variable in class reactor.io.net.http.model.Status
417 Expectation Failed
EXPIRES - Static variable in interface reactor.io.net.http.model.ResponseHeaders
The HTTP Expires header field name.
ext(String) - Method in class reactor.groovy.config.ReactorBuilder
 
ext(String, Object) - Method in class reactor.groovy.config.ReactorBuilder
 
exts(Map<String, Object>) - Method in class reactor.groovy.config.ReactorBuilder
 

F

fail(T) - Static method in class reactor.rx.Streams
Build a Stream that will only emit an error signal to any new subscriber.
FAILED_DEPENDENCY - Static variable in class reactor.io.net.http.model.Status
424 Failed Dependency (WebDAV, RFC4918)
fallback - Variable in class reactor.rx.action.error.FallbackAction
 
FallbackAction<T> - Class in reactor.rx.action.error
 
FallbackAction(Publisher<? extends T>) - Constructor for class reactor.rx.action.error.FallbackAction
 
fanIn(FanInAction<T, ?, V, ? extends FanInAction.InnerSubscriber<T, ?, V>>) - Method in class reactor.rx.Stream
Stream.lift(Supplier) all the nested Publisher values to a new Stream calling the logic inside the provided fanInAction for complex merging strategies.
FanInAction<I,E,O,SUBSCRIBER extends FanInAction.InnerSubscriber<I,E,O>> - Class in reactor.rx.action.combination
The best moment of my life so far, not.
FanInAction(Dispatcher) - Constructor for class reactor.rx.action.combination.FanInAction
 
FanInAction(Dispatcher, List<? extends Publisher<? extends I>>) - Constructor for class reactor.rx.action.combination.FanInAction
 
FanInAction.InnerSubscriber<I,E,O> - Class in reactor.rx.action.combination
 
FanInSubscription<O,E,X,SUBSCRIBER extends FanInAction.InnerSubscriber<O,E,X>> - Class in reactor.rx.action.combination
 
FanInSubscription(Subscriber<? super E>) - Constructor for class reactor.rx.action.combination.FanInSubscription
 
FanInSubscription.InnerSubscription<O,E,SUBSCRIBER extends FanInAction.InnerSubscriber<O,E,?>> - Class in reactor.rx.action.combination
 
FanOutSubscription<O> - Class in reactor.rx.subscription
A composite subscription used to achieve pub/sub pattern.
FanOutSubscription(Stream<O>, PushSubscription<O>, PushSubscription<O>) - Constructor for class reactor.rx.subscription.FanOutSubscription
 
file() - Method in class reactor.io.IO.FileContext
 
FileContext(RandomAccessFile) - Constructor for class reactor.io.IO.FileContext
 
fillInStackTrace() - Method in exception reactor.core.processor.CancelException
 
fillInStackTrace() - Method in exception reactor.core.processor.InsufficientCapacityException
 
fillInStackTrace() - Method in exception reactor.core.reactivestreams.PublisherFactory.PrematureCompleteException
 
Filter - Interface in reactor.bus.filter
A Filter is used to filter a list of items.
filter(List<T>, Object) - Method in interface reactor.bus.filter.Filter
Filters the given List of items.
filter(List<T>, Object) - Method in class reactor.bus.filter.TraceableDelegatingFilter
 
filter(Iterable<T>, Predicate<T>) - Static method in class reactor.fn.Suppliers
Deprecated.
Filter the given Iterable using the given Predicate so that calls to the return Supplier.get() will provide only items from the original collection which pass the predicate test.
filter(Predicate<? super O>) - Method in class reactor.rx.Stream
Evaluate each accepted value against the given Predicate.
filter() - Method in class reactor.rx.Stream
Evaluate each accepted boolean value.
FilterAction<T> - Class in reactor.rx.action.filter
 
FilterAction(Predicate<? super T>) - Constructor for class reactor.rx.action.filter.FilterAction
 
FinallyAction<T> - Class in reactor.rx.action.passive
 
FinallyAction(Consumer<Signal<T>>) - Constructor for class reactor.rx.action.passive.FinallyAction
 
finallyDo(Consumer<Signal<O>>) - Method in class reactor.rx.Stream
Attach a Consumer to this Stream that will observe terminal signal complete|error.
findAvailableTcpPort() - Static method in class reactor.io.net.tcp.support.SocketUtils
Find an available TCP port randomly selected from the range [1024, 65535].
findAvailableTcpPort(int) - Static method in class reactor.io.net.tcp.support.SocketUtils
Find an available TCP port randomly selected from the range [minPort, 65535].
findAvailableTcpPort(int, int) - Static method in class reactor.io.net.tcp.support.SocketUtils
Find an available TCP port randomly selected from the range [minPort, maxPort].
findAvailableTcpPorts(int) - Static method in class reactor.io.net.tcp.support.SocketUtils
Find the requested number of available TCP ports, each randomly selected from the range [1024, 65535].
findAvailableTcpPorts(int, int, int) - Static method in class reactor.io.net.tcp.support.SocketUtils
Find the requested number of available TCP ports, each randomly selected from the range [minPort, maxPort].
findAvailableUdpPort() - Static method in class reactor.io.net.tcp.support.SocketUtils
Find an available UDP port randomly selected from the range [1024, 65535].
findAvailableUdpPort(int) - Static method in class reactor.io.net.tcp.support.SocketUtils
Find an available UDP port randomly selected from the range [minPort, 65535].
findAvailableUdpPort(int, int) - Static method in class reactor.io.net.tcp.support.SocketUtils
Find an available UDP port randomly selected from the range [minPort, maxPort].
findAvailableUdpPorts(int) - Static method in class reactor.io.net.tcp.support.SocketUtils
Find the requested number of available UDP ports, each randomly selected from the range [1024, 65535].
findAvailableUdpPorts(int, int, int) - Static method in class reactor.io.net.tcp.support.SocketUtils
Find the requested number of available UDP ports, each randomly selected from the range [minPort, maxPort].
findOldestStream() - Method in class reactor.rx.Promise
 
findOldestUpstream(Class<P>) - Method in class reactor.rx.action.Action
Utility to find the most ancient subscribed Action.
findSocketTypeName(int) - Static method in class reactor.io.net.impl.zmq.tcp.ZeroMQ
 
first() - Method in class reactor.io.buffer.Buffer
Get the first byte from this Buffer.
first - Variable in class reactor.rx.action.aggregation.BatchAction
 
first(T) - Static method in class reactor.rx.broadcast.BehaviorBroadcaster
Build a Broadcaster, rfirst broadcasting the most recent signal then starting with the passed value, then ready to broadcast values with .Broadcaster#onNext(Object), Broadcaster.onError(Throwable), ().
first(T, Environment) - Static method in class reactor.rx.broadcast.BehaviorBroadcaster
Build a Broadcaster, first broadcasting the most recent signal then starting with the passed value, then ready to broadcast values with Broadcaster.onNext(Object), Broadcaster.onError(Throwable), ().
first(T, Dispatcher) - Static method in class reactor.rx.broadcast.BehaviorBroadcaster
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().
first(T, Environment, Dispatcher) - Static method in class reactor.rx.broadcast.BehaviorBroadcaster
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().
firstCallback(T) - Method in class reactor.rx.action.aggregation.BatchAction
 
firstCallback(T) - Method in class reactor.rx.action.aggregation.SampleAction
 
firstCallback(T) - Method in class reactor.rx.action.aggregation.WindowAction
 
firstEventRouting() - Method in class reactor.bus.spec.EventRoutingComponentSpec
Configures the component's EventRouter to route events to the first of the matching consumers
FirstFilter - Class in reactor.bus.filter
A Filter implementation that returns the first item.
FirstFilter() - Constructor for class reactor.bus.filter.FirstFilter
 
flatMap(Function<? super O, ? extends Publisher<? extends V>>) - Method in class reactor.rx.Promise
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.
flatMap(Function<? super O, ? extends Publisher<? extends V>>) - Method in class reactor.rx.Stream
Assign the given Function to transform the incoming value T into a Stream<O,V> and pass it into another Stream.
flip() - Method in class reactor.io.buffer.Buffer
Flip this Buffer.
floatValue() - Method in class reactor.alloc.RecyclableNumber
 
FlowControlAction<O> - Class in reactor.rx.action.control
 
FlowControlAction(Supplier<? extends CompletableQueue<O>>) - Constructor for class reactor.rx.action.control.FlowControlAction
 
flush - Variable in class reactor.rx.action.aggregation.BatchAction
 
flushCallback(T) - Method in class reactor.rx.action.aggregation.BatchAction
 
flushCallback(T) - Method in class reactor.rx.action.aggregation.BufferAction
 
flushCallback(T) - Method in class reactor.rx.action.aggregation.SampleAction
 
flushCallback(T) - Method in class reactor.rx.action.aggregation.SortAction
 
flushCallback(T) - Method in class reactor.rx.action.aggregation.WindowAction
 
flushConsumer - Variable in class reactor.rx.action.aggregation.BatchAction
 
fn - Variable in class reactor.rx.action.pair.ScanByKeyAction
 
FORBIDDEN - Static variable in class reactor.io.net.http.model.Status
403 Forbidden
forceShutdown() - Method in class reactor.core.dispatch.AbstractLifecycleDispatcher
 
forceShutdown() - Method in class reactor.core.dispatch.MpscDispatcher
 
forceShutdown() - Method in class reactor.core.dispatch.RingBufferDispatcher
 
forceShutdown() - Method in class reactor.core.dispatch.SynchronousDispatcher
 
forceShutdown() - Method in class reactor.core.dispatch.TailRecurseDispatcher
 
forceShutdown() - Method in class reactor.core.dispatch.ThreadPoolExecutorDispatcher
 
forceShutdown() - Method in class reactor.core.dispatch.TraceableDelegatingDispatcher
 
forceShutdown() - Method in class reactor.core.dispatch.WorkQueueDispatcher
 
forceShutdown() - Method in class reactor.core.processor.ExecutorPoweredProcessor
 
forceShutdown() - Method in interface reactor.fn.Resource
Shutdown this Resource, forcibly halting any work currently executing and discarding any tasks that have not yet been executed.
forEach(Consumer<SubscriberWithContext<T, Void>>) - Static method in class reactor.core.reactivestreams.PublisherFactory
Create a Publisher reacting on each available Subscriber read derived with the passed Consumer.
forEach(Consumer<SubscriberWithContext<T, C>>, Function<Subscriber<? super T>, C>) - Static method in class reactor.core.reactivestreams.PublisherFactory
Create a Publisher reacting on each available Subscriber read derived with the passed Consumer.
forEach(Consumer<SubscriberWithContext<T, C>>, Function<Subscriber<? super T>, C>, Consumer<C>) - Static method in class reactor.core.reactivestreams.PublisherFactory
Create a Publisher reacting on each available Subscriber read derived with the passed Consumer.
forEach(Consumer<FanInSubscription.InnerSubscription<O, E, SUBSCRIBER>>) - Method in class reactor.rx.action.combination.FanInSubscription
 
forEach(Consumer<PushSubscription<O>>) - Method in class reactor.rx.subscription.FanOutSubscription
 
FOUND - Static variable in class reactor.io.net.http.model.Status
302 Found
Frame - Class in reactor.io.codec
 
Frame(Buffer, Buffer) - Constructor for class reactor.io.codec.Frame
 
FrameCodec - Class in reactor.io.codec
Codec for decoding data into length-field-based Frames.
FrameCodec(int, FrameCodec.LengthField) - Constructor for class reactor.io.codec.FrameCodec
 
FrameCodec.LengthField - Enum in reactor.io.codec
 
from(Promise<T>, Closure<T>) - Static method in class reactor.groovy.ext.ReactorStaticExtensions
 
FROM - Static variable in interface reactor.io.net.http.model.HttpHeaders
The HTTP From header field name.
from(Iterable<? extends T>) - Static method in class reactor.rx.Streams
Build a Stream whom data is sourced by each element of the passed iterable on subscription request.
from(T[]) - Static method in class reactor.rx.Streams
Build a Stream whom data is sourced by each element of the passed array on subscription request.
from(Future<? extends T>) - Static method in class reactor.rx.Streams
Build a Stream that will only emit the result of the future and then complete.
from(Future<? extends T>, long, TimeUnit) - Static method in class reactor.rx.Streams
Build a Stream that will only emit the result of the future and then complete.
Function<T,R> - Interface in reactor.fn
Implementations of this class perform work on the given parameter and return a result of an optionally different type.
function(Callable<V>) - Static method in class reactor.fn.Functions
Deprecated.
Wrap the given Callable and compose a new Function.
functionFrom(BiFunction<LEFT, RIGHT, V>) - Static method in class reactor.fn.Functions
Deprecated.
Wrap a given BiFunction that applies transformation to a Tuple2 into a Function Tuple2.
Functions - Class in reactor.fn
Deprecated.
Functions() - Constructor for class reactor.fn.Functions
Deprecated.
 
FutureStream<T> - Class in reactor.rx.stream
A Stream that emits a result of a Future and then complete.
FutureStream(Future<? extends T>) - Constructor for class reactor.rx.stream.FutureStream
 
FutureStream(Future<? extends T>, long, TimeUnit) - Constructor for class reactor.rx.stream.FutureStream
 

G

GATEWAY_TIMEOUT - Static variable in class reactor.io.net.http.model.Status
504 Gateway Timeout
generate(Supplier<? extends T>) - Static method in class reactor.rx.Streams
Build a Stream whose data is generated by the passed supplier on subscription request.
get() - Method in class reactor.alloc.AbstractReference
 
get(Class<T>) - Method in class reactor.alloc.EventAllocator
Allocate an object from the internal pool, based on the type of Event.
get() - Method in class reactor.alloc.EventFactorySupplier
 
get(String) - Method in class reactor.bus.Event.Headers
Get the value for the given header.
get() - Method in class reactor.bus.spec.DispatcherComponentSpec
 
get() - Static method in exception reactor.core.processor.CancelException
 
get() - Static method in exception reactor.core.processor.InsufficientCapacityException
 
get() - Static method in class reactor.Environment
Read the context environment.
get() - Method in interface reactor.fn.Supplier
Get an object.
get() - Method in class reactor.fn.support.Tap
Get the value of this Tap, which is the current value of the event stream this tap is consuming.
get(int) - Method in class reactor.fn.tuple.Tuple
Get the object at the given index.
get(int) - Method in class reactor.fn.tuple.Tuple1
 
get(int) - Method in class reactor.fn.tuple.Tuple2
 
get(int) - Method in class reactor.fn.tuple.Tuple3
 
get(int) - Method in class reactor.fn.tuple.Tuple4
 
get(int) - Method in class reactor.fn.tuple.Tuple5
 
get(int) - Method in class reactor.fn.tuple.Tuple6
 
get(int) - Method in class reactor.fn.tuple.Tuple7
 
get(int) - Method in class reactor.fn.tuple.Tuple8
 
get(int) - Method in class reactor.fn.tuple.TupleN
 
get() - Method in class reactor.groovy.config.DispatcherConfigurationBuilder
 
get() - Method in class reactor.groovy.config.EnvironmentBuilder
 
get() - Method in class reactor.groovy.config.ReactorBuilder
 
get() - Method in class reactor.groovy.support.ClosureSupplier
 
get() - Method in class reactor.io.buffer.Buffer.View
 
get(String, ReactorChannelHandler<IN, OUT, HttpChannel<IN, OUT>>) - Method in class reactor.io.net.http.HttpClient
HTTP GET the passed URL.
get(String) - Method in class reactor.io.net.http.HttpClient
HTTP GET the passed URL.
get(String, ReactorChannelHandler<IN, OUT, HttpChannel<IN, OUT>>) - Method in class reactor.io.net.http.HttpServer
Listen for HTTP GET on the passed path to be used as a routing condition.
GET - Static variable in class reactor.io.net.http.model.Method
 
get(String) - Static method in enum reactor.io.net.http.model.Protocol
 
get(String) - Method in interface reactor.io.net.http.model.ReadableHeaders
 
get(String) - Static method in enum reactor.io.net.http.model.Transfer
 
get(String) - Method in class reactor.io.net.impl.netty.http.NettyHttpHeaders
 
get(String) - Method in class reactor.io.net.impl.netty.http.NettyHttpResponseHeaders
 
get(String) - Static method in class reactor.io.net.NetSelectors
get() - Method in class reactor.io.net.Spec.IncrementalBackoffReconnect
 
get() - Method in class reactor.io.net.tcp.ssl.SSLEngineSupplier
 
get(Long) - Method in class reactor.io.queue.ChronicleQueuePersistor
 
get(Long) - Method in class reactor.io.queue.InMemoryQueuePersistor
 
get(Long) - Method in interface reactor.io.queue.QueuePersistor
Return the item with the given id.
get() - Method in class reactor.io.queue.spec.PersistentQueueSpec
 
get() - Method in class reactor.rx.action.Signal
Retrieves the item associated with this (onNext) signal.
get() - Method in class reactor.rx.action.support.TapAndControls
 
get() - Method in class reactor.rx.Promise
Returns the value that completed this promise.
get(Object) - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
getAdditionalProperties() - Method in class reactor.core.config.ReactorConfiguration
Additional configuration properties.
getAge() - Method in class reactor.alloc.AbstractReference
 
getAge() - Method in interface reactor.alloc.Reference
Get the age of this Reference since it's creation.
getAll(String) - Method in interface reactor.io.net.http.model.ReadableHeaders
 
getAll(String) - Method in class reactor.io.net.impl.netty.http.NettyHttpHeaders
 
getAll(String) - Method in class reactor.io.net.impl.netty.http.NettyHttpResponseHeaders
 
getAppender(String) - Method in class reactor.logback.AsyncAppender
 
getAppenderImpl() - Method in class reactor.logback.AsyncAppender
 
getARG_DATA() - Static method in class reactor.groovy.ext.BusExtensions
 
getARG_TOPIC() - Static method in class reactor.groovy.ext.BusExtensions
 
getAt(String) - Method in class reactor.groovy.config.GroovyEnvironment
 
getAvailableCapacity() - Method in class reactor.core.processor.ReactorProcessor
 
getAvailableCapacity() - Method in class reactor.core.processor.RingBufferProcessor
 
getAvailableCapacity() - Method in class reactor.core.processor.RingBufferWorkProcessor
 
getBacklog() - Method in class reactor.core.config.DispatcherConfiguration
Returns the configured backlog, or null if the backlog was not configured
getBacklog() - Method in class reactor.groovy.config.DispatcherConfigurationBuilder
 
getBacklog() - Method in class reactor.logback.AsyncAppender
 
getBasePath() - Method in class reactor.logback.DurableAsyncAppender
 
getBuffer() - Method in class reactor.rx.subscription.ReactiveSubscription
 
getBufferSize() - Method in class reactor.rx.subscription.ReactiveSubscription
 
getCachedDispatcher() - Method in class reactor.Environment
Returns a default cached dispatcher for this environment.
getCachedDispatchers() - Method in class reactor.Environment
Returns the default dispatcher group for this environment.
getCachedDispatchers(String) - Method in class reactor.Environment
Returns the dispatcher factory with the given name.
getCallback() - Method in class reactor.groovy.support.ClosureConsumer
 
getCallback() - Method in class reactor.groovy.support.ClosureEventConsumer
 
getCallback() - Method in class reactor.groovy.support.ClosureEventFunction
 
getCallback() - Method in class reactor.groovy.support.ClosureFunction
 
getCallback() - Method in class reactor.groovy.support.ClosurePredicate
 
getCallback() - Method in class reactor.groovy.support.ClosureReduce
 
getCallback() - Method in class reactor.groovy.support.ClosureSupplier
 
getCapacity() - Method in class reactor.core.processor.ReactorProcessor
 
getCapacity() - Method in class reactor.core.processor.RingBufferProcessor
 
getCapacity() - Method in class reactor.core.processor.RingBufferWorkProcessor
 
getCapacity() - Method in class reactor.core.reactivestreams.SerializedSubscriber
 
getCapacity() - Method in class reactor.core.reactivestreams.SubscriberBarrier
 
getCapacity() - Method in interface reactor.core.support.NonBlocking
Return defined element capacity, used to drive new Subscription request needs.
getCapacity() - Method in class reactor.io.net.ChannelStream
 
getCapacity() - Method in class reactor.rx.action.Action
-------------------------------------------------------------------------------------------------------- ACTION STATE --------------------------------------------------------------------------------------------------------
getCapacity() - Method in class reactor.rx.action.combination.FanInAction.InnerSubscriber
 
getCapacity() - Method in class reactor.rx.action.combination.SwitchAction.SwitchSubscriber
 
getCapacity() - Method in class reactor.rx.action.combination.ZipAction.InnerSubscriber
 
getCapacity() - Method in class reactor.rx.action.support.DefaultSubscriber
 
getCapacity() - Method in class reactor.rx.Promise
 
getCapacity() - Method in class reactor.rx.Stream
 
getCapacity() - Method in class reactor.rx.stream.LiftStream
 
getChannel(EventLoopGroup) - Static method in class reactor.io.net.impl.netty.NettyNativeDetector
 
getChannelStream() - Method in class reactor.io.net.impl.netty.NettyChannelHandlerBridge
 
getCode() - Method in class reactor.io.net.http.model.Status
Returns the code of this Status.
getConnectAddress() - Method in class reactor.io.net.tcp.TcpClient
Get the InetSocketAddress to which this client must connect.
getConsumerRegistry() - Method in class reactor.bus.EventBus
Get the Registry is use to maintain the Consumers currently listening for events on this Reactor.
getContentLength() - Method in interface reactor.io.net.http.model.ResponseHeaders
 
getContentLength() - Method in class reactor.io.net.impl.netty.http.NettyHttpResponseHeaders
 
getContext() - Method in class reactor.core.dispatch.AbstractLifecycleDispatcher
 
getCopyOfAttachedFiltersList() - Method in class reactor.logback.AsyncAppender
 
getData() - Method in class reactor.bus.Event
Get the internal data being wrapped.
getData() - Method in class reactor.io.codec.Frame
 
getDatagramChannel(EventLoopGroup) - Static method in class reactor.io.net.impl.netty.NettyNativeDetector
 
getDate() - Method in interface reactor.io.net.http.model.ReadableHeaders
 
getDate() - Method in class reactor.io.net.impl.netty.http.NettyHttpHeaders
 
getDate() - Method in class reactor.io.net.impl.netty.http.NettyHttpResponseHeaders
 
getDateHeader(String) - Method in interface reactor.io.net.http.model.ReadableHeaders
 
getDateHeader(String) - Method in class reactor.io.net.impl.netty.http.NettyHttpHeaders
 
getDateHeader(String) - Method in class reactor.io.net.impl.netty.http.NettyHttpResponseHeaders
 
getDecoder() - Method in class reactor.io.net.ChannelStream
 
getDefaultCodec() - Method in class reactor.io.net.ReactorPeer
Get the Codec in use.
getDefaultDispatcher() - Method in class reactor.Environment
Returns the default dispatcher for this environment.
getDefaultDispatcher() - Method in class reactor.groovy.config.EnvironmentBuilder
 
getDefaultDispatcher() - Method in class reactor.io.net.ReactorPeer
 
getDefaultDispatcherName() - Method in class reactor.core.config.ReactorConfiguration
Returns the name of the default dispatcher.
getDefaultEnvironment() - Method in class reactor.io.net.ReactorPeer
Get the default environment for all Channel
getDefaultPrefetchSize() - Method in class reactor.io.net.ReactorPeer
Get the default batch read/write size
getDelegate() - Method in class reactor.bus.EventBus.ReplyToConsumer
 
getDelegate() - Method in class reactor.rx.action.combination.FanInSubscription.InnerSubscription
 
getDispatcher() - Method in class reactor.bus.EventBus
Get the Dispatcher currently in use.
getDispatcher(String) - Method in class reactor.Environment
Returns the dispatcher with the given name.
getDispatcher() - Method in class reactor.groovy.config.ReactorBuilder
 
getDispatcher() - Method in class reactor.io.net.ChannelStream
 
getDispatcher() - Method in class reactor.rx.action.aggregation.BatchAction
 
getDispatcher() - Method in class reactor.rx.action.aggregation.WindowShiftAction
 
getDispatcher() - Method in class reactor.rx.action.aggregation.WindowShiftWhenAction
 
getDispatcher() - Method in class reactor.rx.action.aggregation.WindowWhenAction
 
getDispatcher() - Method in class reactor.rx.action.combination.FanInAction
 
getDispatcher() - Method in class reactor.rx.action.combination.SwitchAction
 
getDispatcher() - Method in class reactor.rx.action.control.DispatcherAction
 
getDispatcher() - Method in class reactor.rx.action.control.RepeatAction
 
getDispatcher() - Method in class reactor.rx.action.control.RepeatWhenAction
 
getDispatcher() - Method in class reactor.rx.action.error.RetryAction
 
getDispatcher() - Method in class reactor.rx.action.error.RetryWhenAction
 
getDispatcher() - Method in class reactor.rx.action.terminal.AdaptiveConsumerAction
 
getDispatcher() - Method in class reactor.rx.action.terminal.ConsumerAction
 
getDispatcher() - Method in class reactor.rx.action.transformation.GroupByAction
 
getDispatcher() - Method in class reactor.rx.broadcast.Broadcaster
 
getDispatcher() - Method in class reactor.rx.Stream
Get the dispatcher used to execute signals on this Stream instance.
getDispatcher() - Method in class reactor.rx.stream.LiftStream
 
getDispatcherConfigurations() - Method in class reactor.core.config.ReactorConfiguration
getDispatchErrorHandler() - Method in class reactor.bus.EventBus
 
getEncoder() - Method in class reactor.io.net.ChannelStream
 
getEnd() - Method in class reactor.io.buffer.Buffer.View
Get the end of this range.
getEngine() - Method in class reactor.io.codec.SerializationCodec
 
getEnv() - Method in class reactor.groovy.config.ReactorBuilder
 
getEnvironment() - Method in class reactor.io.net.ChannelStream
 
getEnvironment() - Method in class reactor.rx.action.aggregation.WindowAction
 
getEnvironment() - Method in class reactor.rx.action.aggregation.WindowShiftAction
 
getEnvironment() - Method in class reactor.rx.action.aggregation.WindowShiftWhenAction
 
getEnvironment() - Method in class reactor.rx.action.aggregation.WindowWhenAction
 
getEnvironment() - Method in class reactor.rx.action.transformation.GroupByAction
 
getEnvironment() - Method in class reactor.rx.Promise
 
getEnvironment() - Method in class reactor.rx.Stream
Get the assigned Environment.
getEnvironment() - Method in class reactor.rx.stream.LiftStream
 
getErrorConsumer() - Method in class reactor.bus.Event
Get the internal error consumer callback being wrapped.
getEventArg() - Method in class reactor.groovy.support.ClosureEventConsumer
 
getEventArg() - Method in class reactor.groovy.support.ClosureEventFunction
 
getFacility() - Method in class reactor.io.net.codec.syslog.SyslogMessage
Returns the facility that sent the message
getFilter() - Method in class reactor.bus.routing.ConsumerFilteringRouter
Returns the Filter being used
getFilter() - Method in class reactor.groovy.config.ReactorBuilder
 
getFilterChainDecision(ILoggingEvent) - Method in class reactor.logback.AsyncAppender
 
getFinalCause(Throwable) - Static method in class reactor.core.support.Exceptions
Get the Throwable at the end of the causality-chain for a particular Throwable
getFinalValueCause(Throwable) - Static method in class reactor.core.support.Exceptions
Try to find the last value at the end of the causality-chain for a particular Throwable If the final cause wasn't of type Exceptions.ValueCause, return null;
getFIRST() - Static method in class reactor.groovy.config.ReactorBuilder
 
getHandler() - Method in class reactor.io.net.impl.netty.NettyChannelHandlerBridge
 
getHeaderResolver() - Method in class reactor.bus.selector.MatchAllSelector
 
getHeaderResolver() - Method in class reactor.bus.selector.ObjectSelector
 
getHeaderResolver() - Method in class reactor.bus.selector.RegexSelector
 
getHeaderResolver() - Method in interface reactor.bus.selector.Selector
Return a component that can resolve headers from a key
getHeaderResolver() - Method in class reactor.bus.selector.SetMembershipSelector
 
getHeaderResolver() - Method in class reactor.bus.selector.UriPathSelector
 
getHeaderResolver() - Method in class reactor.bus.selector.UriSelector
 
getHeaderResolver() - Method in class reactor.io.net.http.HttpSelector
 
getHeaders() - Method in class reactor.bus.Event
Get the Event.Headers attached to this event.
getHost() - Method in class reactor.io.net.codec.syslog.SyslogMessage
Returns the host from which the message originated
getHost() - Method in interface reactor.io.net.http.model.ReadableHeaders
 
getHost() - Method in class reactor.io.net.impl.netty.http.NettyHttpHeaders
 
getHost() - Method in class reactor.io.net.impl.netty.http.NettyHttpResponseHeaders
 
getId() - Method in class reactor.bus.Event
Get the globally-unique id of this event.
getId() - Method in class reactor.bus.EventBus
Get the unique, time-used UUID of this Reactor.
getIntProperty(String, int) - Method in class reactor.Environment
Gets the property with the given key, converting it to an integer.
getKey() - Method in class reactor.bus.Event
Get the key this event was notified on.
getListenAddress() - Method in class reactor.io.net.http.HttpServer
Get the address to which this server is bound.
getListenAddress() - Method in class reactor.io.net.impl.netty.http.NettyHttpServer
 
getListenAddress() - Method in class reactor.io.net.tcp.TcpServer
Get the address to which this server is bound.
getListenAddress() - Method in class reactor.io.net.udp.DatagramServer
Get the address to which this server is bound.
getLongProperty(String, long) - Method in class reactor.Environment
Gets the property with the given key, converting it to a long.
getMessage() - Method in class reactor.io.net.codec.syslog.SyslogMessage
Returns the actual message
getMetaClass() - Method in class reactor.groovy.config.DispatcherConfigurationBuilder
 
getMetaClass() - Method in class reactor.groovy.config.DSLUtils
 
getMetaClass() - Method in class reactor.groovy.config.EnvironmentBuilder
 
getMetaClass() - Method in class reactor.groovy.config.GroovyEnvironment
 
getMetaClass() - Method in class reactor.groovy.config.ReactorBuilder
 
getMetaClass() - Method in class reactor.groovy.config.ReactorBuilder.NestedReactorBuilder
 
getMetaClass() - Method in class reactor.groovy.config.ReactorBuilder.SelectorProcessor
 
getMetaClass() - Method in class reactor.groovy.ext.BusExtensions
 
getMetaClass() - Method in class reactor.groovy.ext.ReactorStaticExtensions
 
getMetaClass() - Method in class reactor.groovy.ext.StreamExtensions
 
getMetaClass() - Method in class reactor.groovy.support.ClosureConsumer
 
getMetaClass() - Method in class reactor.groovy.support.ClosureEventConsumer
 
getMetaClass() - Method in class reactor.groovy.support.ClosureEventConsumer.ReplyDecorator
 
getMetaClass() - Method in class reactor.groovy.support.ClosureEventFunction
 
getMetaClass() - Method in class reactor.groovy.support.ClosureFunction
 
getMetaClass() - Method in class reactor.groovy.support.ClosurePredicate
 
getMetaClass() - Method in class reactor.groovy.support.ClosureReduce
 
getMetaClass() - Method in class reactor.groovy.support.ClosureSupplier
 
getMethod() - Method in class reactor.io.net.http.HttpSelector
 
getMulticastInterface() - Method in class reactor.io.net.udp.DatagramServer
Get the NetworkInterface on which multicast will be performed.
getName() - Method in class reactor.core.config.DispatcherConfiguration
Returns the name of the Dispatcher.
getName() - Method in class reactor.groovy.config.DispatcherConfigurationBuilder
 
getName() - Method in class reactor.groovy.config.ReactorBuilder
 
getName() - Method in class reactor.io.net.http.model.Method
 
getName() - Method in class reactor.logback.AsyncAppender
 
getNettyRequest() - Method in class reactor.io.net.impl.netty.http.NettyHttpChannel
 
getNettyResponse() - Method in class reactor.io.net.impl.netty.http.NettyHttpChannel
 
getObject() - Method in class reactor.bus.registry.CachableRegistration
 
getObject() - Method in interface reactor.bus.registry.Registration
The object that was registered
getObject() - Method in class reactor.bus.selector.MatchAllSelector
 
getObject() - Method in class reactor.bus.selector.ObjectSelector
 
getObject() - Method in interface reactor.bus.selector.Selector
Get the object being used for comparisons and equals checks.
getObject() - Method in class reactor.bus.selector.SetMembershipSelector
 
getObject() - Method in class reactor.io.net.http.HttpSelector
 
getObservable() - Method in class reactor.groovy.support.ClosureEventConsumer.ReplyDecorator
 
getOffset() - Method in class reactor.fn.timer.HashWheelTimer.TimerPausable
 
getOptions() - Method in class reactor.io.net.tcp.TcpClient
Get the ClientSocketOptions currently in effect.
getOptions() - Method in class reactor.io.net.tcp.TcpServer
Get the ServerSocketOptions currently in effect.
getOptions() - Method in class reactor.io.net.udp.DatagramServer
Get the ServerSocketOptions currently in effect.
getOrigin() - Method in class reactor.bus.Event.Headers
Get the origin header
getOverride() - Method in class reactor.groovy.config.ReactorBuilder
 
getPrefix() - Method in class reactor.io.codec.Frame
 
getPriority() - Method in class reactor.io.net.codec.syslog.SyslogMessage
Returns the priority assigned to the message
getProcessor() - Method in class reactor.groovy.config.ReactorBuilder.SelectorProcessor
 
getProperty(String, String) - Method in class reactor.Environment
Gets the property with the given key.
getProperty(String) - Method in class reactor.groovy.config.DispatcherConfigurationBuilder
 
getProperty(String) - Method in class reactor.groovy.config.DSLUtils
 
getProperty(String) - Method in class reactor.groovy.config.EnvironmentBuilder
 
getProperty(String) - Method in class reactor.groovy.config.GroovyEnvironment
 
getProperty(String) - Method in class reactor.groovy.config.ReactorBuilder
 
getProperty(String) - Method in class reactor.groovy.config.ReactorBuilder.NestedReactorBuilder
 
getProperty(String) - Method in class reactor.groovy.config.ReactorBuilder.SelectorProcessor
 
getProperty(String) - Method in class reactor.groovy.ext.BusExtensions
 
getProperty(String) - Method in class reactor.groovy.ext.ReactorStaticExtensions
 
getProperty(String) - Method in class reactor.groovy.ext.StreamExtensions
 
getProperty(String) - Method in class reactor.groovy.support.ClosureConsumer
 
getProperty(String) - Method in class reactor.groovy.support.ClosureEventConsumer
 
getProperty(String) - Method in class reactor.groovy.support.ClosureEventConsumer.ReplyDecorator
 
getProperty(String) - Method in class reactor.groovy.support.ClosureEventFunction
 
getProperty(String) - Method in class reactor.groovy.support.ClosureFunction
 
getProperty(String) - Method in class reactor.groovy.support.ClosurePredicate
 
getProperty(String) - Method in class reactor.groovy.support.ClosureReduce
 
getProperty(String) - Method in class reactor.groovy.support.ClosureSupplier
 
getProtocol() - Method in class reactor.io.net.http.HttpSelector
 
getPUB_SUB() - Static method in class reactor.groovy.config.ReactorBuilder
 
getPublisher() - Method in class reactor.rx.subscription.PushSubscription
 
getPublisher() - Method in class reactor.rx.subscription.support.WrappedSubscription
 
getRANDOM() - Static method in class reactor.groovy.config.ReactorBuilder
 
getReactorEnvironment() - Method in class reactor.groovy.config.GroovyEnvironment
 
getReasonPhrase() - Method in class reactor.io.net.http.model.Status
Returns the reason phrase of this Status.
getReferenceCount() - Method in class reactor.alloc.AbstractReference
 
getReferenceCount() - Method in interface reactor.alloc.Reference
Get the current number of references retained to this object.
getReplyTo() - Method in class reactor.bus.Event
Get the key to send replies to.
getReplyTo() - Method in class reactor.groovy.support.ClosureEventConsumer.ReplyDecorator
 
getReplyToObservable() - Method in class reactor.bus.EventBus.ReplyToEvent
 
getResolution() - Method in class reactor.bus.timer.EventTimer
 
getResolution() - Method in class reactor.fn.timer.HashWheelTimer
 
getResolution() - Method in interface reactor.fn.timer.Timer
Get the resolution of this tTimer.
getResponseStatus() - Method in exception reactor.io.net.http.HttpException
 
getROUND_ROBIN() - Static method in class reactor.groovy.config.ReactorBuilder
 
getRouter() - Method in class reactor.bus.EventBus
Get the Router used to route events to Consumers.
getRouter() - Method in class reactor.groovy.config.ReactorBuilder
 
getSelector() - Method in class reactor.bus.registry.CachableRegistration
 
getSelector() - Method in interface reactor.bus.registry.Registration
The Selector that was used when the registration was made.
getSelector() - Method in class reactor.groovy.config.ReactorBuilder.SelectorProcessor
 
getServerChannel(EventLoopGroup) - Static method in class reactor.io.net.impl.netty.NettyNativeDetector
 
getSeverity() - Method in class reactor.io.net.codec.syslog.SyslogMessage
Returns the severity assigned to the message
getSize() - Method in class reactor.core.config.DispatcherConfiguration
Returns the configured size, or null if the size was not configured
getSize() - Method in class reactor.groovy.config.DispatcherConfigurationBuilder
 
getSslOptions() - Method in class reactor.io.net.tcp.TcpClient
Get the SslOptions current in effect.
getSslOptions() - Method in class reactor.io.net.tcp.TcpServer
Get the SslOptions current in effect.
getStart() - Method in class reactor.io.buffer.Buffer.View
Get the start of this range.
getSubscriber() - Method in class reactor.rx.subscription.PushSubscription
 
getSubscription() - Method in class reactor.rx.action.Action
Get the current upstream subscription if any
getSubscription() - Method in class reactor.rx.action.combination.FanInAction
 
getSubscription() - Method in class reactor.rx.action.combination.SwitchAction.SwitchSubscriber
 
getSubscription() - Method in class reactor.rx.action.Signal
Read the subscription associated with this (onSubscribe) signal.
getSubscriptions() - Method in class reactor.rx.subscription.FanOutSubscription
 
getSwitchSubscriber() - Method in class reactor.rx.action.combination.SwitchAction
 
getT1() - Method in class reactor.fn.tuple.Tuple1
Type-safe way to get the first object of this Tuple.
getT1() - Method in class reactor.fn.tuple.TupleN
 
getT2() - Method in class reactor.fn.tuple.Tuple2
Type-safe way to get the second object of this Tuple.
getT2() - Method in class reactor.fn.tuple.TupleN
 
getT3() - Method in class reactor.fn.tuple.Tuple3
Type-safe way to get the third object of this Tuple.
getT3() - Method in class reactor.fn.tuple.TupleN
 
getT4() - Method in class reactor.fn.tuple.Tuple4
Type-safe way to get the fourth object of this Tuple.
getT4() - Method in class reactor.fn.tuple.TupleN
 
getT5() - Method in class reactor.fn.tuple.Tuple5
Type-safe way to get the fifth object of this Tuple.
getT5() - Method in class reactor.fn.tuple.TupleN
 
getT6() - Method in class reactor.fn.tuple.Tuple6
Type-safe way to get the sixth object of this Tuple.
getT6() - Method in class reactor.fn.tuple.TupleN
 
getT7() - Method in class reactor.fn.tuple.Tuple7
Type-safe way to get the seventh object of this Tuple.
getT7() - Method in class reactor.fn.tuple.TupleN
 
getT8() - Method in class reactor.fn.tuple.Tuple8
Type-safe way to get the eighth object of this Tuple.
getT8() - Method in class reactor.fn.tuple.TupleN
 
getTailRecursionPileSize() - Method in class reactor.core.dispatch.SingleThreadDispatcher
 
getThrowable() - Method in class reactor.rx.action.Signal
Read the exception associated with this (onError) signal.
getTimer() - Method in class reactor.Environment
Get the Environment-wide HashWheelTimer.
getTimer() - Static method in class reactor.fn.timer.TimeUtils
 
getTimer() - Method in class reactor.rx.Stream
Get the current timer available if any or try returning the shared Environment one (which may cause an exception if no Environment has been globally initialized)
getTimestamp() - Method in class reactor.io.net.codec.syslog.SyslogMessage
Returns the timestamp for the message
getType() - Method in class reactor.core.config.DispatcherConfiguration
Returns the type of the Dispatcher.
getType() - Method in class reactor.groovy.config.DispatcherConfigurationBuilder
 
getType() - Method in class reactor.rx.action.Signal
Read the type of this signal: Subscribe, Next, Error, or Complete
getUncaughtErrorHandler() - Method in class reactor.bus.EventBus
 
getUriPathSelector() - Method in class reactor.io.net.http.HttpSelector
 
getValue() - Method in exception reactor.core.support.Exceptions.ValueCause
Retrieve the item that the component was trying to emit at the time this exception occurred.
GONE - Static variable in class reactor.io.net.http.model.Status
410 Gone
GroovyEnvironment - Class in reactor.groovy.config
 
GroovyEnvironment() - Constructor for class reactor.groovy.config.GroovyEnvironment
 
groupBy(Function<? super O, ? extends K>) - Method in class reactor.rx.Stream
Re-route incoming values into a dynamically created Stream for each unique key evaluated by the {param keyMapper}.
GroupByAction<T,K> - Class in reactor.rx.action.transformation
Manage a dynamic registry of substreams for a given key extracted from the incoming data.
GroupByAction(Environment, Function<? super T, ? extends K>, Dispatcher) - Constructor for class reactor.rx.action.transformation.GroupByAction
 
groupByMap() - Method in class reactor.rx.action.transformation.GroupByAction
 
GroupedStream<K,T> - Class in reactor.rx.stream
The Stream will complete or fail whever the parent groupBy action terminates itself.
GroupedStream(K) - Constructor for class reactor.rx.stream.GroupedStream
 
GzipCodec<IN,OUT> - Class in reactor.io.codec.compress
 
GzipCodec(Codec<Buffer, IN, OUT>) - Constructor for class reactor.io.codec.compress.GzipCodec
 

H

handler - Variable in class reactor.io.net.impl.netty.NettyChannelHandlerBridge
 
hasError() - Method in class reactor.rx.action.Signal
Read whether this signal is on error and carries the cause.
hashCode() - Method in class reactor.bus.selector.Selectors.AnonymousKey
 
hashCode() - Method in class reactor.fn.tuple.Tuple
 
hashCode() - Method in class reactor.fn.tuple.Tuple1
 
hashCode() - Method in class reactor.fn.tuple.Tuple2
 
hashCode() - Method in class reactor.fn.tuple.Tuple3
 
hashCode() - Method in class reactor.fn.tuple.Tuple4
 
hashCode() - Method in class reactor.fn.tuple.Tuple5
 
hashCode() - Method in class reactor.fn.tuple.Tuple6
 
hashCode() - Method in class reactor.fn.tuple.Tuple7
 
hashCode() - Method in class reactor.fn.tuple.Tuple8
 
hashCode() - Method in class reactor.fn.tuple.TupleN
 
hashCode() - Method in class reactor.io.net.http.model.Method
 
hashCode() - Method in class reactor.io.net.http.model.Status
 
hashCode() - Method in class reactor.rx.action.Signal
 
hashCode() - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
hashCode() - Method in class reactor.rx.subscription.PushSubscription
 
hashCode() - Method in class reactor.rx.subscription.support.WrappedSubscription
 
HashWheelTimer - Class in reactor.fn.timer
Hash Wheel Timer, as per the paper: Hashed and hierarchical timing wheels: http://www.cs.columbia.edu/~nahum/w6998/papers/ton97-timing-wheels.pdf More comprehensive slides, explaining the paper can be found here: http://www.cse.wustl.edu/~cdgill/courses/cs6874/TimingWheels.ppt Hash Wheel timer is an approximated timer that allows performant execution of larger amount of tasks with better performance compared to traditional scheduling.
HashWheelTimer() - Constructor for class reactor.fn.timer.HashWheelTimer
Create a new HashWheelTimer using the given with default resolution of 100 milliseconds and default wheel size.
HashWheelTimer(int) - Constructor for class reactor.fn.timer.HashWheelTimer
Create a new HashWheelTimer using the given timer resolution.
HashWheelTimer(int, int, HashWheelTimer.WaitStrategy) - Constructor for class reactor.fn.timer.HashWheelTimer
Create a new HashWheelTimer using the given timer and .
HashWheelTimer(String, int, int, HashWheelTimer.WaitStrategy, Executor) - Constructor for class reactor.fn.timer.HashWheelTimer
Create a new HashWheelTimer using the given timer and .
HashWheelTimer.BusySpinWait - Class in reactor.fn.timer
BusySpin wait strategy.
HashWheelTimer.SleepWait - Class in reactor.fn.timer
Sleep wait strategy.
HashWheelTimer.TimerPausable<T extends Consumer<Long>> - Class in reactor.fn.timer
Timer Registration
HashWheelTimer.WaitStrategy - Interface in reactor.fn.timer
Wait strategy for the timer
HashWheelTimer.YieldingWait - Class in reactor.fn.timer
Yielding wait strategy.
hasNext() - Method in class reactor.io.queue.ChronicleQueuePersistor
 
hasNext() - Method in class reactor.io.queue.InMemoryQueuePersistor
 
hasNext() - Method in interface reactor.io.queue.QueuePersistor
Are there more items waiting to be returned?
hasPublisher() - Method in class reactor.rx.subscription.PushSubscription
 
hasPublisher() - Method in class reactor.rx.subscription.support.WrappedSubscription
 
hasUnsafe() - Static method in class reactor.core.internal.PlatformDependent
Return true if sun.misc.Unsafe was found on the classpath and can be used for acclerated direct memory access.
hasValue() - Method in class reactor.rx.action.Signal
Has this signal an item associated with it ?
hasWebsocketEndpoints() - Method in class reactor.io.net.http.HttpServer
 
HEAD - Static variable in class reactor.io.net.http.model.Method
 
header(String, String) - Method in class reactor.io.net.http.HttpChannel
Register an HTTP request header
HeaderResolver<T> - Interface in reactor.bus.selector
Responsible for extracting any applicable headers from a key.
Headers(Map<String, Object>) - Constructor for class reactor.bus.Event.Headers
Creates a new Headers instance by copying the contents of the given headers Map.
Headers() - Constructor for class reactor.bus.Event.Headers
Create an empty Headers
headers() - Method in class reactor.io.net.http.HttpChannel
 
Headers - Interface in reactor.io.net.http.model
Header names common to HTTP requests and responses
headers() - Method in class reactor.io.net.impl.netty.http.NettyHttpChannel
 
HEADERS_SENT - Static variable in class reactor.io.net.http.HttpChannel
 
HOST - Static variable in interface reactor.io.net.http.model.HttpHeaders
The HTTP Host header field name.
host(String) - Method in interface reactor.io.net.http.model.WritableHeaders
 
host(String) - Method in class reactor.io.net.impl.netty.http.NettyHttpHeaders
 
host(String) - Method in class reactor.io.net.impl.netty.http.NettyHttpResponseHeaders
 
HOT_SUBSCRIPTION - Static variable in class reactor.rx.broadcast.Broadcaster
 
http(String, Protocol, Method) - Static method in class reactor.io.net.NetSelectors
Creates a Selector based on a URI template.
HTTP_SCHEME - Static variable in class reactor.io.net.http.HttpChannel
 
HTTP_VERSION_NOT_SUPPORTED - Static variable in class reactor.io.net.http.model.Status
505 HTTP Version Not Supported
HttpChannel<IN,OUT> - Class in reactor.io.net.http
A Request/Response ChannelStream extension that provides for several helpers to control HTTP behavior and observe its metadata.
HttpChannel(Environment, long, Dispatcher) - Constructor for class reactor.io.net.http.HttpChannel
 
HttpClient<IN,OUT> - Class in reactor.io.net.http
The base class for a Reactor-based Http client.
HttpClient(Environment, Dispatcher, Codec<Buffer, IN, OUT>, ClientSocketOptions) - Constructor for class reactor.io.net.http.HttpClient
 
httpClient() - Static method in class reactor.io.net.NetStreams
 
httpClient(Function<? super Spec.HttpClientSpec<IN, OUT>, ? extends Spec.HttpClientSpec<IN, OUT>>) - Static method in class reactor.io.net.NetStreams
Bind a new HTTP client to the specified connect address and port.
httpClient(Class<? extends HttpClient>, Function<? super Spec.HttpClientSpec<IN, OUT>, ? extends Spec.HttpClientSpec<IN, OUT>>) - Static method in class reactor.io.net.NetStreams
Bind a new HTTP client to the specified connect address and port.
HttpException - Exception in reactor.io.net.http
An exception for signalling that an error occurred during a communication over HTTP protocol
HttpException(HttpResponseStatus) - Constructor for exception reactor.io.net.http.HttpException
 
HttpHeaders - Interface in reactor.io.net.http.model
 
HTTPS_SCHEME - Static variable in class reactor.io.net.http.HttpChannel
 
HttpSelector - Class in reactor.io.net.http
A Selector to match against ServerRequest
HttpSelector(String) - Constructor for class reactor.io.net.http.HttpSelector
 
HttpSelector(String, Protocol, Method) - Constructor for class reactor.io.net.http.HttpSelector
 
HttpServer<IN,OUT> - Class in reactor.io.net.http
Base functionality needed by all servers that communicate with clients over HTTP.
HttpServer(Environment, Dispatcher, Codec<Buffer, IN, OUT>) - Constructor for class reactor.io.net.http.HttpServer
 
httpServer() - Static method in class reactor.io.net.NetStreams
Build a simple Netty HTTP server listening on 127.0.0.1 and 12012
httpServer(String) - Static method in class reactor.io.net.NetStreams
Build a simple Netty HTTP server listening on 127.0.0.1 and 12012
httpServer(int) - Static method in class reactor.io.net.NetStreams
Build a simple Netty HTTP server listening on 127.0.0.1 and the passed port
httpServer(String, int) - Static method in class reactor.io.net.NetStreams
Build a simple Netty HTTP server listening othe passed bind address and port
httpServer(Function<? super Spec.HttpServerSpec<IN, OUT>, ? extends Spec.HttpServerSpec<IN, OUT>>) - Static method in class reactor.io.net.NetStreams
Build a Netty HTTP Server with the passed factory
httpServer(Class<? extends HttpServer>, Function<? super Spec.HttpServerSpec<IN, OUT>, ? extends Spec.HttpServerSpec<IN, OUT>>) - Static method in class reactor.io.net.NetStreams
 

I

IF_MATCH - Static variable in interface reactor.io.net.http.model.HttpHeaders
The HTTP If-Match header field name.
IF_MODIFIED_SINCE - Static variable in interface reactor.io.net.http.model.HttpHeaders
The HTTP If-Modified-Since header field name.
IF_NONE_MATCH - Static variable in interface reactor.io.net.http.model.HttpHeaders
The HTTP If-None-Match header field name.
IF_RANGE - Static variable in interface reactor.io.net.http.model.HttpHeaders
The HTTP If-Range header field name.
IF_UNMODIFIED_SINCE - Static variable in interface reactor.io.net.http.model.HttpHeaders
The HTTP If-Unmodified-Since header field name.
ignoreError() - Method in class reactor.rx.Stream
Connect an error-proof action that will transform an incoming error signal into a complete signal.
ignoreError(Predicate<? super Throwable>) - Method in class reactor.rx.Stream
Connect an error-proof action based on the given predicate matching the current error.
IgnoreErrorAction<T> - Class in reactor.rx.action.error
 
IgnoreErrorAction(Predicate<? super Throwable>) - Constructor for class reactor.rx.action.error.IgnoreErrorAction
 
include(GroovyEnvironment...) - Method in class reactor.groovy.config.GroovyEnvironment
 
inContext() - Method in class reactor.core.dispatch.AbstractLifecycleDispatcher
Dispatchers can be traced through a contextClassLoader to let producers adapting their dispatching strategy
inContext() - Method in class reactor.core.dispatch.SynchronousDispatcher
 
inContext() - Method in class reactor.core.dispatch.TailRecurseDispatcher
 
inContext() - Method in class reactor.core.dispatch.TraceableDelegatingDispatcher
 
inContext() - Method in interface reactor.core.Dispatcher
A dispatcher context can be bound to the thread(s) it runs on.
incrementSubscribers() - Method in class reactor.core.processor.ReactorProcessor
 
index - Variable in class reactor.rx.action.aggregation.BatchAction
 
indexBlockSize(int) - Method in class reactor.io.queue.spec.PersistentQueueSpec
 
indexOf(byte) - Method in class reactor.io.buffer.Buffer
Search the buffer and find the position of the first occurrence of the given byte.
indexOf(byte, int, int) - Method in class reactor.io.buffer.Buffer
Search the buffer and find the position of the first occurrence of the given byte staring at the start position and searching until (and including) the end position.
init() - Method in class reactor.groovy.config.ReactorBuilder
 
initialize() - Static method in class reactor.Environment
Create and assign a context environment bound to the current classloader.
initialize(Consumer<Throwable>) - Static method in class reactor.Environment
Create and assign a context environment bound to the current classloader.
initializeIfEmpty() - Static method in class reactor.Environment
Create and assign a context environment bound to the current classloader only if it not already set.
initUpstreamPublisherAndCapacity() - Method in class reactor.rx.action.combination.CombineLatestAction
 
initUpstreamPublisherAndCapacity() - Method in class reactor.rx.action.combination.FanInAction
 
InMemoryQueuePersistor<T> - Class in reactor.io.queue
A QueuePersistor implementations that stores items in-memory.
InMemoryQueuePersistor() - Constructor for class reactor.io.queue.InMemoryQueuePersistor
 
InnerSubscription(Subscription, SUBSCRIBER) - Constructor for class reactor.rx.action.combination.FanInSubscription.InnerSubscription
 
input() - Method in class reactor.rx.action.CompositeAction
 
inputStream() - Method in class reactor.io.buffer.Buffer
Create an InputStream capable of reading the bytes from the internal ByteBuffer.
INSTANCE - Static variable in class reactor.core.dispatch.SynchronousDispatcher
 
INSTANCE - Static variable in class reactor.core.dispatch.TailRecurseDispatcher
 
INSTANCE - Static variable in exception reactor.core.processor.CancelException
 
INSTANCE - Static variable in exception reactor.core.reactivestreams.PublisherFactory.PrematureCompleteException
 
INSTANCE - Static variable in exception reactor.core.support.ReactorFatalException
 
instance() - Static method in exception reactor.core.support.ReactorFatalException
 
INSUFFICIENT_STORAGE - Static variable in class reactor.io.net.http.model.Status
507 Insufficient Storage (WebDAV, RFC4918)
InsufficientCapacityException - Exception in reactor.core.processor
Exception thrown when the it is not possible to dispatch a signal a Dispatcher.
intercept(Publisher<? extends I>, Function<Subscriber<? super O>, SubscriberBarrier<I, O>>) - Static method in class reactor.core.reactivestreams.PublisherFactory
Create a Publisher intercepting all source signals with a SubscriberBarrier per Subscriber provided by the given barrierProvider.
INTERNAL_SERVER_ERROR - Static variable in class reactor.io.net.http.model.Status
500 Internal Server Error
interval(long) - Method in class reactor.io.net.Spec.IncrementalBackoffReconnect
Set the reconnection interval.
intValue() - Method in class reactor.alloc.RecyclableNumber
 
invokeAll(Collection<? extends Callable<T>>) - Method in class reactor.core.processor.util.SingleUseExecutor
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class reactor.core.processor.util.SingleUseExecutor
 
invokeAny(Collection<? extends Callable<T>>) - Method in class reactor.core.processor.util.SingleUseExecutor
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class reactor.core.processor.util.SingleUseExecutor
 
invokeCallbackOrReturn(Consumer<IN>, IN) - Static method in class reactor.io.codec.Codec
 
invokeMethod(String, Object) - Method in class reactor.groovy.config.DispatcherConfigurationBuilder
 
invokeMethod(String, Object) - Method in class reactor.groovy.config.DSLUtils
 
invokeMethod(String, Object) - Method in class reactor.groovy.config.EnvironmentBuilder
 
invokeMethod(String, Object) - Method in class reactor.groovy.config.GroovyEnvironment
 
invokeMethod(String, Object) - Method in class reactor.groovy.config.ReactorBuilder
 
invokeMethod(String, Object) - Method in class reactor.groovy.config.ReactorBuilder.NestedReactorBuilder
 
invokeMethod(String, Object) - Method in class reactor.groovy.config.ReactorBuilder.SelectorProcessor
 
invokeMethod(String, Object) - Method in class reactor.groovy.ext.BusExtensions
 
invokeMethod(String, Object) - Method in class reactor.groovy.ext.ReactorStaticExtensions
 
invokeMethod(String, Object) - Method in class reactor.groovy.ext.StreamExtensions
 
invokeMethod(String, Object) - Method in class reactor.groovy.support.ClosureConsumer
 
invokeMethod(String, Object) - Method in class reactor.groovy.support.ClosureEventConsumer
 
invokeMethod(String, Object) - Method in class reactor.groovy.support.ClosureEventConsumer.ReplyDecorator
 
invokeMethod(String, Object) - Method in class reactor.groovy.support.ClosureEventFunction
 
invokeMethod(String, Object) - Method in class reactor.groovy.support.ClosureFunction
 
invokeMethod(String, Object) - Method in class reactor.groovy.support.ClosurePredicate
 
invokeMethod(String, Object) - Method in class reactor.groovy.support.ClosureReduce
 
invokeMethod(String, Object) - Method in class reactor.groovy.support.ClosureSupplier
 
IO - Class in reactor.io
A factory for Reactive basic IO operations such as File read/write, Byte read and Codec decoding.
IO.FileContext - Class in reactor.io
A read access to the source file
IOStreams - Class in reactor.rx
A Streams add-on to work with IO components such as ChronicleStreams.
isAssignable(Class<?>, Class<?>, String) - Static method in class reactor.core.support.Assert
Assert that superType.isAssignableFrom(subType) is true.
isAttached(Appender<ILoggingEvent>) - Method in class reactor.logback.AsyncAppender
 
isCancelAfterUse() - Method in class reactor.bus.registry.CachableRegistration
 
isCancelAfterUse() - Method in interface reactor.bus.registry.Registration
Whether to cancel this Registration after use or not.
isCancelAfterUse() - Method in class reactor.fn.timer.HashWheelTimer.TimerPausable
 
isCancelled() - Method in class reactor.bus.registry.CachableRegistration
 
isCancelled() - Method in interface reactor.bus.registry.Registration
Has this been cancelled?
isCancelled() - Method in class reactor.core.reactivestreams.SubscriberWithContext
 
isCancelled() - Method in class reactor.core.reactivestreams.SubscriptionWithContext
 
isCancelled() - Method in class reactor.fn.timer.HashWheelTimer.TimerPausable
Check whether the current Registration is cancelled
isComplete() - Method in class reactor.core.queue.CompletableBlockingQueue
 
isComplete() - Method in class reactor.core.queue.CompletableLinkedQueue
 
isComplete() - Method in interface reactor.core.queue.CompletableQueue
Deprecated.
Get the number of items persisted right now.
isComplete() - Method in class reactor.io.queue.PersistentQueue
 
isComplete() - Method in class reactor.rx.Promise
Indicates whether this Promise has been completed with either an error or a value
isComplete() - Method in class reactor.rx.subscription.FanOutSubscription
 
isComplete() - Method in class reactor.rx.subscription.PushSubscription
 
isComplete() - Method in class reactor.rx.subscription.ReactiveSubscription
 
isComplete() - Method in class reactor.rx.subscription.support.WrappedSubscription
 
isDelimitingBuffer() - Method in class reactor.io.buffer.Buffer
Is this instance a delimiting Buffer
isDynamic() - Method in class reactor.io.buffer.Buffer
Whether this Buffer is fixed-length or not.
isEmpty() - Method in class reactor.core.queue.internal.MpscLinkedQueue
 
isEmpty() - Method in interface reactor.io.net.http.model.ReadableHeaders
 
isEmpty() - Method in class reactor.io.net.impl.netty.http.NettyHttpHeaders
 
isEmpty() - Method in class reactor.io.net.impl.netty.http.NettyHttpResponseHeaders
 
isEmpty() - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
isEmpty() - Method in class reactor.rx.subscription.FanOutSubscription
 
isError() - Method in class reactor.rx.Promise
Indicates whether this Promise has been completed with an error.
isEventArg() - Method in class reactor.groovy.support.ClosureEventConsumer
 
isEventArg() - Method in class reactor.groovy.support.ClosureEventFunction
 
isIncludeCallerData() - Method in class reactor.logback.AsyncAppender
 
isInstanceOf(Class<?>, Object, String) - Static method in class reactor.core.support.Assert
Assert that the provided object is an instance of the provided class.
isKeepAlive() - Method in class reactor.io.net.http.HttpChannel
Is the request keepAlive
isKeepAlive() - Method in interface reactor.io.net.http.model.WritableHeaders
 
isKeepAlive() - Method in class reactor.io.net.impl.netty.http.NettyHttpChannel
 
isKeepAlive() - Method in class reactor.io.net.impl.netty.http.NettyHttpHeaders
 
isKeepAlive() - Method in class reactor.io.net.impl.netty.http.NettyHttpResponseHeaders
 
isNull(Object, String) - Static method in class reactor.core.support.Assert
Assert that an object is null .
isOnComplete() - Method in class reactor.rx.action.Signal
Indicates whether this signal represents an onComplete event.
isOnError() - Method in class reactor.rx.action.Signal
Indicates whether this signal represents an onError event.
isOnNext() - Method in class reactor.rx.action.Signal
Indicates whether this signal represents an onNext event.
isOnSubscribe() - Method in class reactor.rx.action.Signal
Indicates whether this signal represents an onSubscribe event.
isOpen() - Method in class reactor.io.buffer.Buffer
 
isOpen() - Method in class reactor.io.IO.FileContext
 
isOverride() - Method in class reactor.groovy.config.ReactorBuilder
 
isPaused() - Method in class reactor.bus.registry.CachableRegistration
 
isPaused() - Method in interface reactor.bus.registry.Registration
Whether this Registration has been paused or not.
isPaused() - Method in class reactor.fn.timer.HashWheelTimer.TimerPausable
Check whether the current Registration is paused
isPending() - Method in class reactor.rx.Promise
Indicates whether this Promise has yet to be completed with a value or an error.
isPublishing() - Method in class reactor.rx.action.Action
 
isPublishing() - Method in interface reactor.rx.action.Control
Check if the current stream is emitting any signal.
isPublishing() - Method in class reactor.rx.action.support.TapAndControls
 
isReactivePull(Dispatcher, long) - Method in class reactor.core.processor.ReactorProcessor
 
isReactivePull(Dispatcher, long) - Method in class reactor.core.reactivestreams.SerializedSubscriber
 
isReactivePull(Dispatcher, long) - Method in class reactor.core.reactivestreams.SubscriberBarrier
 
isReactivePull(Dispatcher, long) - Method in interface reactor.core.support.NonBlocking
Get the assigned Dispatcher.
isReactivePull(Dispatcher, long) - Method in class reactor.rx.action.aggregation.BatchAction
 
isReactivePull(Dispatcher, long) - Method in class reactor.rx.action.combination.CombineLatestAction.InnerSubscriber
 
isReactivePull(Dispatcher, long) - Method in class reactor.rx.action.combination.FanInAction.InnerSubscriber
 
isReactivePull(Dispatcher, long) - Method in class reactor.rx.action.combination.MergeAction.InnerSubscriber
 
isReactivePull(Dispatcher, long) - Method in class reactor.rx.action.combination.SwitchAction.SwitchSubscriber
 
isReactivePull(Dispatcher, long) - Method in class reactor.rx.action.combination.ZipAction.InnerSubscriber
 
isReactivePull(Dispatcher, long) - Method in class reactor.rx.action.control.DispatcherAction
 
isReactivePull(Dispatcher, long) - Method in class reactor.rx.action.control.FlowControlAction
 
isReactivePull(Dispatcher, long) - Method in class reactor.rx.action.control.ThrottleRequestAction
 
isReactivePull(Dispatcher, long) - Method in class reactor.rx.action.control.ThrottleRequestWhenAction
 
isReactivePull(Dispatcher, long) - Method in class reactor.rx.action.support.DefaultSubscriber
 
isReactivePull(Dispatcher, long) - Method in class reactor.rx.action.terminal.AdaptiveConsumerAction
 
isReactivePull(Dispatcher, long) - Method in class reactor.rx.action.terminal.ConsumerAction
 
isReactivePull(Dispatcher, long) - Method in class reactor.rx.Promise
 
isReactivePull(Dispatcher, long) - Method in class reactor.rx.Stream
 
isShutdown() - Method in class reactor.core.processor.util.SingleUseExecutor
 
isStarted() - Method in class reactor.logback.AsyncAppender
 
isSuccess() - Method in class reactor.rx.Promise
Indicates whether this Promise has been successfully completed a value.
isTerminated() - Method in class reactor.core.processor.util.SingleUseExecutor
 
isTrue(boolean, String) - Static method in class reactor.core.support.Assert
Assert a boolean expression, throwing IllegalArgumentException if the test result is false.
isTrue(boolean) - Static method in class reactor.core.support.Assert
Assert a boolean expression, throwing IllegalArgumentException if the test result is false.
IterableStream<T> - Class in reactor.rx.stream
A Stream that emits Iterable values one by one and then complete.
IterableStream() - Constructor for class reactor.rx.stream.IterableStream
 
iterator() - Method in class reactor.bus.Event.Headers
Returns an unmodifiable Iterator over a copy of this Headers' contents.
iterator() - Method in class reactor.bus.registry.CachingRegistry
 
iterator() - Method in class reactor.bus.registry.SimpleCachingRegistry
 
iterator() - Method in class reactor.core.queue.internal.MpscLinkedQueue
 
iterator() - Method in class reactor.Environment
 
iterator() - Method in class reactor.fn.tuple.Tuple
 
iterator() - Method in class reactor.fn.tuple.Tuple1
 
iterator() - Method in class reactor.fn.tuple.Tuple2
 
iterator() - Method in class reactor.fn.tuple.Tuple3
 
iterator() - Method in class reactor.fn.tuple.Tuple4
 
iterator() - Method in class reactor.fn.tuple.Tuple5
 
iterator() - Method in class reactor.fn.tuple.Tuple6
 
iterator() - Method in class reactor.fn.tuple.Tuple7
 
iterator() - Method in class reactor.fn.tuple.Tuple8
 
iterator() - Method in class reactor.fn.tuple.TupleN
 
iterator() - Method in class reactor.io.buffer.Buffer
 
iterator() - Method in class reactor.io.queue.ChronicleQueuePersistor
 
iterator() - Method in class reactor.io.queue.InMemoryQueuePersistor
 
iterator() - Method in class reactor.io.queue.PersistentQueue
 
iteratorForAppenders() - Method in class reactor.logback.AsyncAppender
 

J

J(String, Filter...) - Static method in class reactor.bus.selector.JsonPathSelector
 
JacksonJsonCodec<IN,OUT> - Class in reactor.io.codec.json
 
JacksonJsonCodec() - Constructor for class reactor.io.codec.json.JacksonJsonCodec
 
JacksonJsonCodec(ObjectMapper) - Constructor for class reactor.io.codec.json.JacksonJsonCodec
 
JavaSerializationCodec<T> - Class in reactor.io.codec
Codec to transform Java objects into Buffers and visa-versa.
JavaSerializationCodec() - Constructor for class reactor.io.codec.JavaSerializationCodec
 
join(InetAddress, NetworkInterface) - Method in class reactor.io.net.impl.netty.udp.NettyDatagramServer
 
join(InetAddress, NetworkInterface) - Method in class reactor.io.net.udp.DatagramServer
Join a multicast group.
join(InetAddress) - Method in class reactor.io.net.udp.DatagramServer
Join a multicast group.
join() - Method in class reactor.rx.Stream
Stream.lift(Supplier) all the nested Publisher values to a new Stream until one of them complete.
join(Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are aggregated from the passed publishers (1 element consumed for each merged publisher. resulting in an array of size of .
join(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are aggregated from the passed publishers (1 element consumed for each merged publisher. resulting in an array of size of .
join(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are aggregated from the passed publishers (1 element consumed for each merged publisher. resulting in an array of size of .
join(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are aggregated from the passed publishers (1 element consumed for each merged publisher. resulting in an array of size of .
join(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are aggregated from the passed publishers (1 element consumed for each merged publisher. resulting in an array of size of .
join(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are aggregated from the passed publishers (1 element consumed for each merged publisher. resulting in an array of size of .
join(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are aggregated from the passed publishers (1 element consumed for each merged publisher. resulting in an array of size of .
join(List<? extends Publisher<? extends T>>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are aggregated from the passed publishers (1 element consumed for each merged publisher. resulting in an array of size of .
join(Publisher<? extends Publisher<T>>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are aggregated from the passed publishers (1 element consumed for each merged publisher. resulting in an array of size of .
joinWith(Publisher<? extends V>) - Method in class reactor.rx.Stream
Stream.lift(Supplier) all the nested Publisher values to a new Stream until one of them complete.
joinZipper() - Static method in class reactor.rx.action.combination.ZipAction
 
JsonCodec<IN,OUT> - Class in reactor.io.codec.json
A codec for decoding JSON into Java objects and encoding Java objects into JSON.
JsonCodec(Class<IN>) - Constructor for class reactor.io.codec.json.JsonCodec
Creates a new JsonCodec that will create instances of inputType when decoding.
JsonCodec(Class<IN>, Module) - Constructor for class reactor.io.codec.json.JsonCodec
Creates a new JsonCodec that will create instances of inputType when decoding.
JsonCodec(Class<IN>, Module, Byte) - Constructor for class reactor.io.codec.json.JsonCodec
Creates a new JsonCodec that will create instances of inputType when decoding.
JsonPathSelector - Class in reactor.bus.selector
 
JsonPathSelector(ObjectMapper, String, Filter...) - Constructor for class reactor.bus.selector.JsonPathSelector
 
JsonPathSelector(String, Filter...) - Constructor for class reactor.bus.selector.JsonPathSelector
 
jsonPathSelector(String, Filter...) - Static method in class reactor.bus.selector.JsonPathSelector
 
just(T) - Static method in class reactor.rx.Streams
Build a Stream whom data is sourced by the passed element on subscription request.
just(T, T) - Static method in class reactor.rx.Streams
Build a Stream whom data is sourced by each element of the passed iterable on subscription request.
just(T, T, T) - Static method in class reactor.rx.Streams
Build a Stream whom data is sourced by each element of the passed iterable on subscription request.
just(T, T, T, T) - Static method in class reactor.rx.Streams
Build a Stream whom data is sourced by each element of the passed iterable on subscription request.
just(T, T, T, T, T) - Static method in class reactor.rx.Streams
Build a Stream whom data is sourced by each element of the passed iterable on subscription request.
just(T, T, T, T, T, T) - Static method in class reactor.rx.Streams
Build a Stream whom data is sourced by each element of the passed iterable on subscription request.
just(T, T, T, T, T, T, T) - Static method in class reactor.rx.Streams
Build a Stream whom data is sourced by each element of the passed iterable on subscription request.
just(T, T, T, T, T, T, T, T) - Static method in class reactor.rx.Streams
Build a Stream whom data is sourced by each element of the passed iterable on subscription request.

K

keepAlive() - Method in class reactor.io.net.config.CommonSocketOptions
Returns a boolean indicating whether or not SO_KEEPALIVE is enabled
keepAlive(boolean) - Method in class reactor.io.net.config.CommonSocketOptions
Enables or disables SO_KEEPALIVE.
keepAlive(boolean) - Method in class reactor.io.net.http.HttpChannel
set the request keepAlive if true otherwise remove the existing connection keep alive header
keepAlive(boolean) - Method in interface reactor.io.net.http.model.WritableHeaders
 
keepAlive(boolean) - Method in class reactor.io.net.impl.netty.http.NettyHttpChannel
 
keepAlive(boolean) - Method in class reactor.io.net.impl.netty.http.NettyHttpHeaders
 
keepAlive(boolean) - Method in class reactor.io.net.impl.netty.http.NettyHttpResponseHeaders
 
keepAlive() - Method in class reactor.rx.Stream
Prevent a Stream to be cancelled.
key() - Method in class reactor.rx.stream.GroupedStream
 
key(K) - Method in class reactor.rx.stream.MapStream.MutableSignal
 
key() - Method in class reactor.rx.stream.MapStream.Signal
 
keyCodec - Variable in class reactor.rx.stream.io.ChronicleReaderStream
 
keyCodec() - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
keyManagerFactoryAlgorithm() - Method in class reactor.io.net.config.SslOptions
 
keyManagerFactoryAlgorithm(String) - Method in class reactor.io.net.config.SslOptions
 
keyManagerPasswd() - Method in class reactor.io.net.config.SslOptions
 
keyManagerPasswd(String) - Method in class reactor.io.net.config.SslOptions
 
keySet() - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
keystoreFile() - Method in class reactor.io.net.config.SslOptions
 
keystoreFile(String) - Method in class reactor.io.net.config.SslOptions
 
keystorePasswd() - Method in class reactor.io.net.config.SslOptions
 
keystorePasswd(String) - Method in class reactor.io.net.config.SslOptions
 
KryoCodec<IN,OUT> - Class in reactor.io.codec.kryo
 
KryoCodec() - Constructor for class reactor.io.codec.kryo.KryoCodec
 
KryoCodec(Kryo, boolean) - Constructor for class reactor.io.codec.kryo.KryoCodec
 
KryoPoolCodec<IN,OUT> - Class in reactor.io.codec.kryo
 
KryoPoolCodec() - Constructor for class reactor.io.codec.kryo.KryoPoolCodec
 
KryoPoolCodec(KryoFactory, boolean) - Constructor for class reactor.io.codec.kryo.KryoPoolCodec
 
KryoPoolCodec(KryoPool, boolean) - Constructor for class reactor.io.codec.kryo.KryoPoolCodec
 

L

last() - Method in class reactor.io.buffer.Buffer
Get the last byte from this Buffer.
last() - Method in class reactor.rx.Stream
Create a new Stream that will signal the last element observed before complete signal.
LAST_MODIFIED - Static variable in interface reactor.io.net.http.model.ResponseHeaders
The HTTP Last-Modified header field name.
LastAction<T> - Class in reactor.rx.action.aggregation
 
LastAction() - Constructor for class reactor.rx.action.aggregation.LastAction
 
lastId() - Method in class reactor.io.queue.ChronicleQueuePersistor
 
lastId() - Method in class reactor.io.queue.InMemoryQueuePersistor
 
lastId() - Method in interface reactor.io.queue.QueuePersistor
Get the value of the last item to have been persisted.
leave(InetAddress, NetworkInterface) - Method in class reactor.io.net.impl.netty.udp.NettyDatagramServer
 
leave(InetAddress, NetworkInterface) - Method in class reactor.io.net.udp.DatagramServer
Leave a multicast group.
leave(InetAddress) - Method in class reactor.io.net.udp.DatagramServer
Leave a multicast group.
leftIndex - Variable in class reactor.rx.action.combination.FanInSubscription
 
leftShift(Stream<T>, Consumer<T>) - Static method in class reactor.groovy.ext.StreamExtensions
 
leftShift(Promise<T>, Consumer<T>) - Static method in class reactor.groovy.ext.StreamExtensions
 
leftShift(P, T) - Static method in class reactor.groovy.ext.StreamExtensions
 
LENGTH_REQUIRED - Static variable in class reactor.io.net.http.model.Status
411 Length Required
LengthFieldCodec<IN,OUT> - Class in reactor.io.codec
A codec that uses a length-field at the start of each chunk to denote the chunk's size.
LengthFieldCodec(Codec<Buffer, IN, OUT>) - Constructor for class reactor.io.codec.LengthFieldCodec
Create a length-field codec that reads the first integer as the length of the remaining message.
LengthFieldCodec(int, Codec<Buffer, IN, OUT>) - Constructor for class reactor.io.codec.LengthFieldCodec
Create a length-field codec that reads the first short, integer, or long as the length of the remaining message, and prepends a short, integer, long to its output.
lift(Supplier<? extends Action<O, V>>) - Method in class reactor.rx.Stream
Defer the subscription of an Action to the actual pipeline.
LiftStream<O,V> - Class in reactor.rx.stream
A Stream wrapper that defers a parent stream subscription to the child action subscribe() call.
LiftStream(Stream<O>, Supplier<? extends Action<O, V>>) - Constructor for class reactor.rx.stream.LiftStream
 
limit(int) - Method in class reactor.io.buffer.Buffer
Sets this buffer's limit.
limit() - Method in class reactor.io.buffer.Buffer
Provides the current limit of the internal ByteBuffer.
LINE_FEED_CODEC - Static variable in class reactor.io.codec.StandardCodecs
A DelimitedCodec that works with String data delimited by a line-feed ('\n') character
linger() - Method in class reactor.io.net.config.CommonSocketOptions
Returns the configuration of SO_LINGER.
linger(int) - Method in class reactor.io.net.config.CommonSocketOptions
Configures SO_LINGER
LINK - Static variable in interface reactor.io.net.http.model.ResponseHeaders
The HTTP Link header field name.
listen(int) - Method in class reactor.io.net.Spec.PeerSpec
The port on which this server should listen, assuming it should bind to all available addresses.
listen(String, int) - Method in class reactor.io.net.Spec.PeerSpec
The host and port on which this server should listen.
listen(InetSocketAddress) - Method in class reactor.io.net.Spec.PeerSpec
The InetSocketAddress on which this server should listen.
listenAddress - Variable in class reactor.io.net.Spec.PeerSpec
 
listenAddress - Variable in class reactor.io.net.tcp.TcpServer
 
listenAddresses() - Method in class reactor.io.net.impl.zmq.ZeroMQServerSocketOptions
 
listenAddresses(String) - Method in class reactor.io.net.impl.zmq.ZeroMQServerSocketOptions
 
loadProfile(String) - Method in class reactor.core.config.PropertiesConfigurationReader
 
localCache - Variable in class reactor.rx.stream.io.ChronicleReaderStream
 
localCache() - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
LOCATION - Static variable in interface reactor.io.net.http.model.ResponseHeaders
The HTTP Location header field name.
LOCKED - Static variable in class reactor.io.net.http.model.Status
423 Locked (WebDAV, RFC4918)
log - Static variable in class reactor.io.net.ChannelStream
 
log - Static variable in class reactor.io.net.impl.netty.NettyChannelHandlerBridge
 
log() - Method in class reactor.rx.Stream
Attach a Logger to this Stream that will observe any signal emitted.
log(String) - Method in class reactor.rx.Stream
Attach a Logger to this Stream that will observe any signal emitted.
LoggerAction<T> - Class in reactor.rx.action.passive
 
LoggerAction(String) - Constructor for class reactor.rx.action.passive.LoggerAction
 
longValue() - Method in class reactor.alloc.RecyclableNumber
 

M

main(String...) - Static method in class reactor.logback.DurableLogUtility
 
makeAllocator(Class<T>) - Method in class reactor.alloc.EventAllocator
Make a new allocator for Events with generic type of
map(Function<? super O, V>) - Method in class reactor.rx.Promise
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.
map(Function<? super O, ? extends V>) - Method in class reactor.rx.Stream
Assign the given Function to transform the incoming value T into a V and pass it into another Stream.
MapAction<T,V> - Class in reactor.rx.action.transformation
 
MapAction(Function<? super T, ? extends V>) - Constructor for class reactor.rx.action.transformation.MapAction
 
mapListener - Variable in class reactor.rx.action.pair.ScanByKeyAction
 
MapStream<K,V> - Class in reactor.rx.stream
A SubscribableMap is an event-driven Map that signals logged operations to its subscribers.
MapStream() - Constructor for class reactor.rx.stream.MapStream
 
MapStream.MutableSignal<K,V> - Class in reactor.rx.stream
 
MapStream.Operation - Enum in reactor.rx.stream
 
MapStream.Signal<K,V> - Class in reactor.rx.stream
 
markAsDeferredStart() - Method in class reactor.rx.subscription.PushSubscription
 
markAsStarted() - Method in class reactor.rx.subscription.PushSubscription
 
match(String) - Method in class reactor.bus.selector.UriPathTemplate
Matches the template against the given uri returning a map of path parameters extracted from the uri, keyed by the names in the template.
matchAll() - Static method in class reactor.bus.selector.Selectors
Creates a Selector that matches all objects.
MatchAllSelector - Class in reactor.bus.selector
Implementation of Selector that matches all objects.
MatchAllSelector() - Constructor for class reactor.bus.selector.MatchAllSelector
 
matches(Object) - Method in class reactor.bus.selector.ClassSelector
 
matches(Object) - Method in class reactor.bus.selector.JsonPathSelector
 
matches(Object) - Method in class reactor.bus.selector.MatchAllSelector
 
matches(K) - Method in class reactor.bus.selector.ObjectSelector
 
matches(Object) - Method in class reactor.bus.selector.PredicateSelector
 
matches(Object) - Method in class reactor.bus.selector.RegexSelector
 
matches(T) - Method in interface reactor.bus.selector.Selector
Indicates whether this Selector matches the key.
matches(Object) - Method in class reactor.bus.selector.SetMembershipSelector
 
matches(Object) - Method in class reactor.bus.selector.UriPathSelector
 
matches(String) - Method in class reactor.bus.selector.UriPathTemplate
Tests the given uri against this template, returning true if the uri matches the template, false otherwise.
matches(Object) - Method in class reactor.bus.selector.UriSelector
 
matches(HttpChannel) - Method in class reactor.io.net.http.HttpSelector
 
materialize() - Method in class reactor.rx.Stream
Transform the incoming onSubscribe, onNext, onError and onComplete signals into Signal.
MaterializeAction<T> - Class in reactor.rx.action.transformation
 
MaterializeAction() - Constructor for class reactor.rx.action.transformation.MaterializeAction
 
MAX_BUFFER_SIZE - Static variable in class reactor.io.buffer.Buffer
The maximum allowed buffer size in bytes.
MAX_FORWARDS - Static variable in interface reactor.io.net.http.model.HttpHeaders
The HTTP Max-Forwards header field name.
maxAttempts(long) - Method in class reactor.io.net.Spec.IncrementalBackoffReconnect
Sets the number of time that Reactor will attempt to connect or reconnect before giving up.
maxCapacity(long) - Method in class reactor.rx.subscription.PushSubscription
 
maxCapacity - Variable in class reactor.rx.subscription.ReactiveSubscription
 
maxCapacity(long) - Method in class reactor.rx.subscription.ReactiveSubscription
 
maxCapacity(long) - Method in class reactor.rx.subscription.support.WrappedSubscription
 
maxInterval(long) - Method in class reactor.io.net.Spec.IncrementalBackoffReconnect
Set the maximum reconnection interval that will be applied if the multiplier is set to a value greather than one.
merge() - Method in class reactor.rx.Stream
Stream.lift(Supplier) all the nested Publisher values to a new Stream.
merge(Iterable<? extends Publisher<? extends T>>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are generated by the passed publishers.
merge(Publisher<? extends Publisher<E>>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are generated by the passed publishers.
merge(Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the passed publishers.
merge(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the passed publishers.
merge(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the passed publishers.
merge(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the passed publishers.
merge(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the passed publishers.
merge(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the passed publishers.
merge(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the passed publishers.
MergeAction<O> - Class in reactor.rx.action.combination
 
MergeAction(Dispatcher) - Constructor for class reactor.rx.action.combination.MergeAction
 
MergeAction(Dispatcher, List<? extends Publisher<? extends O>>) - Constructor for class reactor.rx.action.combination.MergeAction
 
MergeAction.InnerSubscriber<I> - Class in reactor.rx.action.combination
 
mergedStream() - Method in class reactor.rx.action.combination.DynamicMergeAction
 
mergeWith(Publisher<? extends O>) - Method in class reactor.rx.Stream
Stream.lift(Supplier) all the nested Publisher values from this current upstream and from the passed publisher.
method() - Method in class reactor.io.net.http.HttpChannel
 
method - Variable in class reactor.io.net.http.HttpSelector
 
Method - Class in reactor.io.net.http.model
A Model representation of supported HTTP Methods
Method(String) - Constructor for class reactor.io.net.http.model.Method
 
method() - Method in class reactor.io.net.impl.netty.http.NettyHttpChannel
 
METHOD_NOT_ALLOWED - Static variable in class reactor.io.net.http.model.Status
405 Method Not Allowed
mod(Stream<T>, BiFunction<T, T, T>) - Static method in class reactor.groovy.ext.StreamExtensions
 
MOVED_PERMANENTLY - Static variable in class reactor.io.net.http.model.Status
301 Moved Permanently
MPSC - Static variable in class reactor.Environment
The name of the default mpsc dispatcher
MpscDispatcher - Class in reactor.core.dispatch
Implementation of a Dispatcher that uses a MpscLinkedQueue to queue tasks to execute.
MpscDispatcher(String) - Constructor for class reactor.core.dispatch.MpscDispatcher
Creates a new MpscDispatcher with the given name.
MpscDispatcher(String, int) - Constructor for class reactor.core.dispatch.MpscDispatcher
Creates a new MpscDispatcher with the given name.
MpscLinkedQueue<E> - Class in reactor.core.queue.internal
A MultiProduceSingleConsumer impl. borrowed from Netty project which is also borrowing this from various sources.
MpscLinkedQueueNode<T> - Class in reactor.core.queue.internal
 
MpscLinkedQueueNode() - Constructor for class reactor.core.queue.internal.MpscLinkedQueueNode
 
MULTI_STATUS - Static variable in class reactor.io.net.http.model.Status
207 Multi-Status (WebDAV, RFC2518)
multicastInterface(NetworkInterface) - Method in class reactor.io.net.Spec.DatagramServerSpec
Set the interface to use for multicast.
MULTIPLE_CHOICES - Static variable in class reactor.io.net.http.model.Status
300 Multiple Choices
multiplier(long) - Method in class reactor.io.net.Spec.IncrementalBackoffReconnect
Set the backoff multiplier.
MultiThreadDispatcher - Class in reactor.core.dispatch
Base implementation for multi-threaded dispatchers
MultiThreadDispatcher(int, int) - Constructor for class reactor.core.dispatch.MultiThreadDispatcher
 
MultiThreadDispatcher.MultiThreadTask - Class in reactor.core.dispatch
 
MultiThreadTask() - Constructor for class reactor.core.dispatch.MultiThreadDispatcher.MultiThreadTask
 
MutableSignal<T> - Class in reactor.core.processor
 
MutableSignal() - Constructor for class reactor.core.processor.MutableSignal
 
MutableSignal() - Constructor for class reactor.rx.stream.MapStream.MutableSignal
 
MutableSignal.Type - Enum in reactor.core.processor
 

N

name - Variable in class reactor.rx.stream.io.ChronicleReaderStream
 
NamedDaemonThreadFactory - Class in reactor.core.support
A thread factory that creates named daemon threads.
NamedDaemonThreadFactory(String) - Constructor for class reactor.core.support.NamedDaemonThreadFactory
Creates a new thread factory that will name its threads <prefix>-<n>, where <prefix> is the given prefix and <n> is the count of threads created thus far by this class.
NamedDaemonThreadFactory(String, ClassLoader) - Constructor for class reactor.core.support.NamedDaemonThreadFactory
Creates a new thread factory that will name its threads <prefix>-<n>, where <prefix> is the given prefix and <n> is the count of threads created thus far by this class.
NamedDaemonThreadFactory(String, ClassLoader, Thread.UncaughtExceptionHandler, boolean) - Constructor for class reactor.core.support.NamedDaemonThreadFactory
 
names() - Method in interface reactor.io.net.http.model.ReadableHeaders
 
names() - Method in class reactor.io.net.impl.netty.http.NettyHttpHeaders
 
names() - Method in class reactor.io.net.impl.netty.http.NettyHttpResponseHeaders
 
negate(Predicate<? super T>) - Static method in class reactor.fn.Predicates
Deprecated.
Returns a Predicate which negates the given Predicate.
nervous() - Method in class reactor.core.dispatch.RingBufferDispatcher
 
nervous() - Method in class reactor.core.dispatch.wait.AgileWaitingStrategy
 
nervous() - Method in interface reactor.core.dispatch.wait.WaitingMood
Turn the mood into aggressive CPU demand mode to effectively give an an additional resources boost to the underlying component.
nervous() - Method in class reactor.core.dispatch.WorkQueueDispatcher
 
nest() - Method in class reactor.rx.Stream
Create a new Stream whose only value will be the current instance of the Stream.
NestedReactorBuilder(String, ReactorBuilder, EventBus) - Constructor for class reactor.groovy.config.ReactorBuilder.NestedReactorBuilder
 
NetSelectors - Class in reactor.io.net
Helper methods for creating Selectors.
NetSelectors() - Constructor for class reactor.io.net.NetSelectors
 
NetStreams - Class in reactor.io.net
A Streams add-on to work with network facilities from reactor-net, e.g.: {@code //echo server NetStreams.tcpServer(1234).start( connection -> ch.writeWith(connection) ); NetStreams.tcpClient(1234).start( connection -> connection //Listen for any incoming data on that connection, they will be Buffer an IOStream can easily decode .nest() .flatMap(self -> IOStreams.decode(new StringCodec('\n'), self)) .consume(log::info); //Push anything from the publisher returned, here a simple Reactor Stream.
NetStreams.HttpClientFactory<IN,OUT> - Interface in reactor.io.net
 
NetStreams.HttpServerFactory<IN,OUT> - Interface in reactor.io.net
 
NetStreams.TcpClientFactory<IN,OUT> - Interface in reactor.io.net
 
NetStreams.TcpServerFactory<IN,OUT> - Interface in reactor.io.net
 
NetStreams.UdpServerFactory<IN,OUT> - Interface in reactor.io.net
 
NettyChannelHandlerBridge<IN,OUT> - Class in reactor.io.net.impl.netty
Netty ChannelInboundHandler implementation that passes data to a Reactor ChannelStream.
NettyChannelHandlerBridge(ReactorChannelHandler<IN, OUT, ChannelStream<IN, OUT>>, NettyChannelStream<IN, OUT>) - Constructor for class reactor.io.net.impl.netty.NettyChannelHandlerBridge
 
NettyChannelHandlerBridge.ChannelInputSubscriberEvent<IN> - Class in reactor.io.net.impl.netty
An event to attach a Subscriber to the NettyChannelStream created by NettyChannelHandlerBridge
NettyChannelStream<IN,OUT> - Class in reactor.io.net.impl.netty
ReactorChannel implementation that delegates to Netty.
NettyChannelStream(Environment, Codec<Buffer, IN, OUT>, long, Dispatcher, Channel) - Constructor for class reactor.io.net.impl.netty.NettyChannelStream
 
NettyClientSocketOptions - Class in reactor.io.net.impl.netty
 
NettyClientSocketOptions() - Constructor for class reactor.io.net.impl.netty.NettyClientSocketOptions
 
NettyDatagramServer<IN,OUT> - Class in reactor.io.net.impl.netty.udp
DatagramServer implementation built on Netty.
NettyDatagramServer(Environment, Dispatcher, InetSocketAddress, NetworkInterface, ServerSocketOptions, Codec<Buffer, IN, OUT>) - Constructor for class reactor.io.net.impl.netty.udp.NettyDatagramServer
 
NettyHttpChannel<IN,OUT> - Class in reactor.io.net.impl.netty.http
 
NettyHttpChannel(NettyChannelStream<IN, OUT>, HttpRequest) - Constructor for class reactor.io.net.impl.netty.http.NettyHttpChannel
 
NettyHttpClient<IN,OUT> - Class in reactor.io.net.impl.netty.http
A Netty-based TcpClient.
NettyHttpClient(Environment, Dispatcher, Supplier<InetSocketAddress>, ClientSocketOptions, SslOptions, Codec<Buffer, IN, OUT>) - Constructor for class reactor.io.net.impl.netty.http.NettyHttpClient
Creates a new NettyTcpClient that will use the given env for configuration and the given reactor to send events.
NettyHttpClientHandler<IN,OUT> - Class in reactor.io.net.impl.netty.http
 
NettyHttpClientHandler(ReactorChannelHandler<IN, OUT, ChannelStream<IN, OUT>>, NettyChannelStream<IN, OUT>) - Constructor for class reactor.io.net.impl.netty.http.NettyHttpClientHandler
 
NettyHttpHeaders - Class in reactor.io.net.impl.netty.http
 
NettyHttpHeaders(HttpRequest) - Constructor for class reactor.io.net.impl.netty.http.NettyHttpHeaders
 
NettyHttpResponseHeaders - Class in reactor.io.net.impl.netty.http
 
NettyHttpResponseHeaders(HttpResponse) - Constructor for class reactor.io.net.impl.netty.http.NettyHttpResponseHeaders
 
NettyHttpServer<IN,OUT> - Class in reactor.io.net.impl.netty.http
A Netty-based TcpServer implementation
NettyHttpServer(Environment, Dispatcher, InetSocketAddress, ServerSocketOptions, SslOptions, Codec<Buffer, IN, OUT>) - Constructor for class reactor.io.net.impl.netty.http.NettyHttpServer
 
NettyHttpServerHandler<IN,OUT> - Class in reactor.io.net.impl.netty.http
Conversion between Netty types and Reactor types (NettyHttpChannel and Buffer).
NettyHttpServerHandler(ReactorChannelHandler<IN, OUT, ChannelStream<IN, OUT>>, NettyChannelStream<IN, OUT>) - Constructor for class reactor.io.net.impl.netty.http.NettyHttpServerHandler
 
NettyHttpWSClientHandler<IN,OUT> - Class in reactor.io.net.impl.netty.http
 
NettyHttpWSClientHandler(ReactorChannelHandler<IN, OUT, ChannelStream<IN, OUT>>, NettyChannelStream<IN, OUT>, WebSocketClientHandshaker) - Constructor for class reactor.io.net.impl.netty.http.NettyHttpWSClientHandler
 
NettyHttpWSServerHandler<IN,OUT> - Class in reactor.io.net.impl.netty.http
Conversion between Netty types and Reactor types (NettyHttpChannel and Buffer).
NettyHttpWSServerHandler(String, String, NettyHttpServerHandler<IN, OUT>) - Constructor for class reactor.io.net.impl.netty.http.NettyHttpWSServerHandler
 
NettyNativeDetector - Class in reactor.io.net.impl.netty
 
NettyNativeDetector() - Constructor for class reactor.io.net.impl.netty.NettyNativeDetector
 
NettyServerSocketOptions - Class in reactor.io.net.impl.netty
Extends standard ServerSocketOptions with Netty-specific options.
NettyServerSocketOptions() - Constructor for class reactor.io.net.impl.netty.NettyServerSocketOptions
 
NettyTcpClient<IN,OUT> - Class in reactor.io.net.impl.netty.tcp
A Netty-based TcpClient.
NettyTcpClient(Environment, Dispatcher, Supplier<InetSocketAddress>, ClientSocketOptions, SslOptions, Codec<Buffer, IN, OUT>) - Constructor for class reactor.io.net.impl.netty.tcp.NettyTcpClient
Creates a new NettyTcpClient that will use the given env for configuration and the given reactor to send events.
NettyTcpServer<IN,OUT> - Class in reactor.io.net.impl.netty.tcp
A Netty-based TcpServer implementation
NettyTcpServer(Environment, Dispatcher, InetSocketAddress, ServerSocketOptions, SslOptions, Codec<Buffer, IN, OUT>) - Constructor for class reactor.io.net.impl.netty.tcp.NettyTcpServer
 
NETWORK_AUTHENTICATION_REQUIRED - Static variable in class reactor.io.net.http.model.Status
511 Network Authentication Required (RFC6585)
never() - Static method in class reactor.fn.Predicates
Deprecated.
Returns a Predicate which always evaluates to false.
never() - Static method in class reactor.rx.Streams
Build a Stream that will never emit anything.
newAtomicReferenceFieldUpdater(Class<U>, String) - Static method in class reactor.core.internal.PlatformDependent
 
newCachedDispatchers(int) - Static method in class reactor.Environment
 
newCachedDispatchers(int, String) - Static method in class reactor.Environment
 
newDispatcher() - Static method in class reactor.Environment
Register a dispatcher into the context environment.
newDispatcher(int) - Static method in class reactor.Environment
Register a dispatcher into the context environment.
newDispatcher(String, int) - Static method in class reactor.Environment
Register a dispatcher into the context environment.
newDispatcher(int, int) - Static method in class reactor.Environment
Register a dispatcher into the context environment.
newDispatcher(String, int, int) - Static method in class reactor.Environment
Register a dispatcher into the context environment.
newDispatcher(int, int, DispatcherType) - Static method in class reactor.Environment
Register a dispatcher into the context environment.
newDispatcher(String, int, int, DispatcherType) - Static method in class reactor.Environment
Register a dispatcher into the context environment.
newDispatcherLike(String) - Static method in class reactor.Environment
Register a dispatcher into the context environment.
newDispatcherLike(String, String) - Static method in class reactor.Environment
Register a dispatcher into the context environment.
newEventLoopGroup(int, ThreadFactory) - Static method in class reactor.io.net.impl.netty.NettyNativeDetector
 
newFanOutCachedDispatchers(int, String) - Static method in class reactor.Environment
 
newThread(Runnable) - Method in class reactor.core.support.NamedDaemonThreadFactory
 
next - Variable in class reactor.rx.action.aggregation.BatchAction
 
next(T) - Static method in class reactor.rx.action.Signal
Creates and returns a Signal of variety Type.NEXT, and assigns it a value.
next() - Method in class reactor.rx.Stream
Return the promise of the next triggered signal.
nextCallback(T) - Method in class reactor.rx.action.aggregation.BatchAction
 
nextCallback(T) - Method in class reactor.rx.action.aggregation.BufferAction
 
nextCallback(T) - Method in class reactor.rx.action.aggregation.SampleAction
 
nextCallback(T) - Method in class reactor.rx.action.aggregation.SortAction
 
nextCallback(T) - Method in class reactor.rx.action.aggregation.WindowAction
 
NO_CAPACITY - Static variable in class reactor.rx.action.Action
 
NO_CONTENT - Static variable in class reactor.io.net.http.model.Status
204 No Content
NON_AUTHORITATIVE_INFORMATION - Static variable in class reactor.io.net.http.model.Status
203 Non-Authoritative Information (since HTTP/1.1)
NonBlocking - Interface in reactor.core.support
A dispatcher aware component
NOOP_CODEC - Static variable in interface reactor.io.net.Spec
 
NOOP_DECODER - Static variable in interface reactor.io.net.Spec
 
NOT_ACCEPTABLE - Static variable in class reactor.io.net.http.model.Status
406 Not Acceptable
NOT_EXTENDED - Static variable in class reactor.io.net.http.model.Status
510 Not Extended (RFC2774)
NOT_FOUND - Static variable in class reactor.io.net.http.model.Status
404 Not Found
NOT_IMPLEMENTED - Static variable in class reactor.io.net.http.model.Status
501 Not Implemented
NOT_MODIFIED - Static variable in class reactor.io.net.http.model.Status
304 Not Modified
NOT_STARTED - Static variable in class reactor.rx.action.combination.FanInAction
 
notEmpty(Object[], String) - Static method in class reactor.core.support.Assert
Assert that an array has elements; that is, it must not be null and must have at least one element.
notify(Object, T) - Method in interface reactor.bus.Bus
Notify this component that an Event is ready to be processed.
notify(Object, Event<?>) - Method in class reactor.bus.EventBus
 
notify(Publisher<?>, Object) - Method in class reactor.bus.EventBus
Pass values accepted by this Stream into the given Bus, notifying with the given key.
notify(Publisher<? extends T>, Function<? super T, ?>) - Method in class reactor.bus.EventBus
Pass values accepted by this Stream into the given Bus, notifying with the given key.
notify(Object, Supplier<? extends Event<?>>) - Method in class reactor.bus.EventBus
Notify this component that the given Supplier can provide an event that's ready to be processed.
notify(Object) - Method in class reactor.bus.EventBus
Notify this component that the consumers registered with a Selector that matches the key should be triggered with a null input argument.
notify(Bus, Object, T) - Static method in class reactor.groovy.ext.BusExtensions
 
notify(Bus, Object, Supplier<Event<T>>) - Static method in class reactor.groovy.ext.BusExtensions
 
notify(Bus, Object) - Static method in class reactor.groovy.ext.BusExtensions
 
notify(Bus, String, Closure<T>) - Static method in class reactor.groovy.ext.BusExtensions
 
notify(Bus, Map) - Static method in class reactor.groovy.ext.BusExtensions
 
NotifyConsumer<T> - Class in reactor.bus.support
A Consumer that notifies an observable of each value that it has accepted.
NotifyConsumer(Object, Bus<?>) - Constructor for class reactor.bus.support.NotifyConsumer
Creates a new NotifyConsumer that will notify the given observable using the given notifyKey.
notNull(Object, String) - Static method in class reactor.core.support.Assert
Assert that an object is not null .
notNull(Object) - Static method in class reactor.core.support.Assert
Assert that an object is not null .

O

object(T) - Static method in class reactor.bus.selector.Selectors
Creates a Selector based on the given object.
ObjectSelector<K,T> - Class in reactor.bus.selector
Selector implementation that uses the Object.hashCode() and Object.equals(Object) methods of the internal object to determine a match.
ObjectSelector(T) - Constructor for class reactor.bus.selector.ObjectSelector
Create a new Selector instance from the given object.
objectSelector(T) - Static method in class reactor.bus.selector.ObjectSelector
Helper method to create a Selector from the given object.
observe(Consumer<? super O>) - Method in class reactor.rx.Stream
Attach a Consumer to this Stream that will observe any values accepted by this Stream.
observeCancel(Consumer<Void>) - Method in class reactor.rx.Stream
Attach a Consumer to this Stream that will observe any cancel signal
observeComplete(Consumer<Void>) - Method in class reactor.rx.Stream
Attach a Consumer to this Stream that will observe any complete signal
observeError(Class<E>, BiConsumer<Object, ? super E>) - Method in class reactor.rx.Stream
Assign an error handler that will pass eventual associated values and exceptions of the given type.
observeStart(Consumer<? super Subscription>) - Method in class reactor.rx.Stream
Attach a Consumer to this Stream that will observe any onSubscribe signal
observeSubscribe(Consumer<? super Subscriber<? super O>>) - Method in class reactor.rx.Stream
Attach a Consumer to this Stream that will observe any subscribe signal
of(Object[]) - Static method in class reactor.fn.tuple.Tuple
Create a TupleN with the given object.
of(List<?>) - Static method in class reactor.fn.tuple.Tuple
Create a TupleN with the given object.
of(T1) - Static method in class reactor.fn.tuple.Tuple
Create a Tuple1 with the given object.
of(T1, T2) - Static method in class reactor.fn.tuple.Tuple
Create a Tuple2 with the given objects.
of(T1, T2, T3) - Static method in class reactor.fn.tuple.Tuple
Create a Tuple3 with the given objects.
of(T1, T2, T3, T4) - Static method in class reactor.fn.tuple.Tuple
Create a Tuple4 with the given objects.
of(T1, T2, T3, T4, T5) - Static method in class reactor.fn.tuple.Tuple
Create a Tuple5 with the given objects.
of(T1, T2, T3, T4, T5, T6) - Static method in class reactor.fn.tuple.Tuple
Create a Tuple6 with the given objects.
of(T1, T2, T3, T4, T5, T6, T7) - Static method in class reactor.fn.tuple.Tuple
Create a Tuple7 with the given objects.
of(T1, T2, T3, T4, T5, T6, T7, T8) - Static method in class reactor.fn.tuple.Tuple
Create a Tuple8 with the given objects.
offer(E) - Method in class reactor.core.queue.internal.MpscLinkedQueue
 
offer(T) - Method in class reactor.io.queue.ChronicleQueuePersistor
 
offer(T) - Method in class reactor.io.queue.InMemoryQueuePersistor
 
offer(T) - Method in class reactor.io.queue.PersistentQueue
 
offer(T) - Method in interface reactor.io.queue.QueuePersistor
Persist and return the last Long id of the item.
offerAll(Collection<T>) - Method in class reactor.io.queue.ChronicleQueuePersistor
 
offerAll(Collection<T>) - Method in class reactor.io.queue.InMemoryQueuePersistor
 
offerAll(Collection<T>) - Method in interface reactor.io.queue.QueuePersistor
Persist N items in batch and return a Long id of the last item.
OK - Static variable in class reactor.io.net.http.model.Status
200 OK
on(Selector, Consumer<V>) - Method in interface reactor.bus.Bus
Register a Consumer to be triggered when a notification matches the given Selector.
on(Selector, Consumer<T>) - Method in class reactor.bus.EventBus
 
on(Selector) - Method in class reactor.bus.EventBus
Attach a Publisher to the Bus with the specified Selector.
on(Closure) - Method in class reactor.groovy.config.ReactorBuilder
 
on(String, Closure) - Method in class reactor.groovy.config.ReactorBuilder
 
on(Consumer) - Method in class reactor.groovy.config.ReactorBuilder
 
on(String, Consumer) - Method in class reactor.groovy.config.ReactorBuilder
 
on(Selector, Closure) - Method in class reactor.groovy.config.ReactorBuilder
 
on(Selector, Consumer) - Method in class reactor.groovy.config.ReactorBuilder
 
on() - Method in class reactor.io.net.impl.netty.http.NettyHttpChannel
 
on() - Method in class reactor.io.net.impl.netty.NettyChannelStream
 
on() - Method in class reactor.io.net.impl.zmq.ZeroMQChannelStream
 
on() - Method in interface reactor.io.net.ReactorChannel
Assign event handlers to certain channel lifecycle events.
onComplete() - Method in class reactor.core.processor.ExecutorPoweredProcessor
 
onComplete() - Method in class reactor.core.processor.RingBufferProcessor
 
onComplete() - Method in class reactor.core.processor.RingBufferWorkProcessor
 
onComplete(RingBuffer<MutableSignal<E>>) - Static method in class reactor.core.processor.util.RingBufferSubscriberUtils
 
onComplete() - Method in class reactor.core.reactivestreams.SerializedSubscriber
 
onComplete() - Method in class reactor.core.reactivestreams.SubscriberBarrier
 
onComplete() - Method in class reactor.core.reactivestreams.SubscriberWithContext
 
onComplete() - Method in class reactor.logback.AsyncAppender
 
onComplete() - Method in class reactor.rx.action.Action
 
onComplete() - Method in class reactor.rx.action.combination.ConcatAction
 
onComplete() - Method in class reactor.rx.action.combination.DynamicMergeAction
 
onComplete() - Method in class reactor.rx.action.combination.FanInAction.InnerSubscriber
 
onComplete() - Method in class reactor.rx.action.combination.SwitchAction.SwitchSubscriber
 
onComplete() - Method in class reactor.rx.action.combination.ZipAction.InnerSubscriber
 
onComplete() - Method in class reactor.rx.action.CompositeAction
 
onComplete() - Method in class reactor.rx.action.control.DispatcherAction
 
onComplete() - Method in class reactor.rx.action.control.RepeatAction
 
onComplete() - Method in class reactor.rx.action.control.RepeatWhenAction
 
onComplete() - Method in class reactor.rx.action.control.ThrottleRequestWhenAction
 
onComplete() - Method in class reactor.rx.action.support.DefaultSubscriber
 
onComplete() - Method in class reactor.rx.broadcast.Broadcaster
 
onComplete() - Method in class reactor.rx.broadcast.SerializedBroadcaster
 
onComplete(Consumer<Promise<O>>) - Method in class reactor.rx.Promise
Assign a Consumer that will either be invoked later, when the Promise is completed by either setting a value or propagating an error, or, if this Promise has already been fulfilled, is immediately scheduled to be executed on the current Dispatcher.
onComplete() - Method in class reactor.rx.Promise
 
onComplete() - Method in class reactor.rx.subscription.FanOutSubscription
 
onComplete() - Method in class reactor.rx.subscription.PushSubscription
 
onComplete() - Method in class reactor.rx.subscription.ReactiveSubscription
 
onError(Throwable) - Method in class reactor.core.processor.RingBufferProcessor
 
onError(Throwable) - Method in class reactor.core.processor.RingBufferWorkProcessor
 
onError(Throwable, RingBuffer<MutableSignal<E>>) - Static method in class reactor.core.processor.util.RingBufferSubscriberUtils
 
onError(Throwable) - Method in class reactor.core.reactivestreams.SerializedSubscriber
 
onError(Throwable) - Method in class reactor.core.reactivestreams.SubscriberBarrier
 
onError(Throwable) - Method in class reactor.core.reactivestreams.SubscriberWithContext
 
onError(Throwable) - Method in class reactor.logback.AsyncAppender
 
onError(Throwable) - Method in class reactor.rx.action.Action
 
onError(Throwable) - Method in class reactor.rx.action.combination.DynamicMergeAction
 
onError(Throwable) - Method in class reactor.rx.action.combination.FanInAction.InnerSubscriber
 
onError(Throwable) - Method in class reactor.rx.action.combination.SwitchAction.SwitchSubscriber
 
onError(Throwable) - Method in class reactor.rx.action.CompositeAction
 
onError(Throwable) - Method in class reactor.rx.action.control.DispatcherAction
 
onError(Throwable) - Method in class reactor.rx.action.control.FlowControlAction
 
onError(Throwable) - Method in class reactor.rx.action.error.RetryAction
 
onError(Throwable) - Method in class reactor.rx.action.error.RetryWhenAction
 
onError(Throwable) - Method in class reactor.rx.action.support.DefaultSubscriber
 
onError(Throwable) - Method in class reactor.rx.broadcast.Broadcaster
 
onError(Throwable) - Method in class reactor.rx.broadcast.SerializedBroadcaster
 
onError(Consumer<Throwable>) - Method in class reactor.rx.Promise
Assign a Consumer that will either be invoked later, when the Promise is completed with an error, or, if this Promise has already been fulfilled, is immediately scheduled to be executed on the current Dispatcher.
onError(Throwable) - Method in class reactor.rx.Promise
 
onError(Throwable) - Method in class reactor.rx.subscription.FanOutSubscription
 
onError(Throwable) - Method in class reactor.rx.subscription.PushSubscription
 
onErrorResumeNext(Publisher<? extends O>) - Method in class reactor.rx.Stream
Subscribe to a fallback publisher when any exception occurs.
onErrorResumeNext(Class<E>, Publisher<? extends O>) - Method in class reactor.rx.Stream
Subscribe to a fallback publisher when exceptions of the given type occur, otherwise propagate the error.
onErrorReturn(Function<Throwable, ? extends O>) - Method in class reactor.rx.Stream
Produce a default value if any exception occurs.
onErrorReturn(Class<E>, Function<E, ? extends O>) - Method in class reactor.rx.Stream
Produce a default value when exceptions of the given type occur, otherwise propagate the error.
onLift() - Method in class reactor.rx.stream.LiftStream
 
onNext(E) - Method in class reactor.core.processor.RingBufferProcessor
 
onNext(E) - Method in class reactor.core.processor.RingBufferWorkProcessor
 
onNext(E, RingBuffer<MutableSignal<E>>) - Static method in class reactor.core.processor.util.RingBufferSubscriberUtils
 
onNext(T) - Method in class reactor.core.reactivestreams.SerializedSubscriber
 
onNext(I) - Method in class reactor.core.reactivestreams.SubscriberBarrier
 
onNext(T) - Method in class reactor.core.reactivestreams.SubscriberWithContext
 
onNext(ILoggingEvent) - Method in class reactor.logback.AsyncAppender
 
onNext(I) - Method in class reactor.rx.action.Action
 
onNext(O) - Method in class reactor.rx.action.combination.CombineLatestAction.InnerSubscriber
 
onNext(Publisher<? extends I>) - Method in class reactor.rx.action.combination.DynamicMergeAction
 
onNext(E) - Method in class reactor.rx.action.combination.FanInAction
 
onNext(I) - Method in class reactor.rx.action.combination.MergeAction.InnerSubscriber
 
onNext(Publisher<? extends T>) - Method in class reactor.rx.action.combination.SwitchAction
 
onNext(T) - Method in class reactor.rx.action.combination.SwitchAction.SwitchSubscriber
 
onNext(O) - Method in class reactor.rx.action.combination.ZipAction.InnerSubscriber
 
onNext(E) - Method in class reactor.rx.action.CompositeAction
 
onNext(T) - Method in class reactor.rx.action.control.DispatcherAction
 
onNext(O) - Method in class reactor.rx.action.support.DefaultSubscriber
 
onNext(O) - Method in class reactor.rx.broadcast.BehaviorBroadcaster
 
onNext(O) - Method in class reactor.rx.broadcast.Broadcaster
 
onNext(O) - Method in class reactor.rx.broadcast.SerializedBroadcaster
 
onNext(O) - Method in class reactor.rx.Promise
 
onNext(O) - Method in class reactor.rx.subscription.DropSubscription
 
onNext(O) - Method in class reactor.rx.subscription.FanOutSubscription
 
onNext(O) - Method in class reactor.rx.subscription.PushSubscription
 
onNext(O) - Method in class reactor.rx.subscription.ReactiveSubscription
 
onOverflowBuffer(Supplier<? extends CompletableQueue<O>>) - Method in class reactor.rx.action.Action
 
onOverflowBuffer() - Method in class reactor.rx.Stream
Attach a No-Op Action that only serves the purpose of buffering incoming values if not enough demand is signaled downstream.
onOverflowBuffer(Supplier<? extends CompletableQueue<O>>) - Method in class reactor.rx.Stream
Attach a No-Op Action that only serves the purpose of buffering incoming values if not enough demand is signaled downstream.
onOverflowDrop() - Method in class reactor.rx.Stream
Attach a No-Op Action that only serves the purpose of dropping incoming values if not enough demand is signaled downstream.
onPut() - Method in class reactor.rx.stream.MapStream
Return a Stream of key/value tuples for only new or updated entries.
onRemove() - Method in class reactor.rx.stream.MapStream
Return a Stream of key/value tuples for only removed entries.
onRequest(long) - Method in class reactor.rx.action.combination.FanInSubscription
 
onRequest(long) - Method in class reactor.rx.subscription.PushSubscription
 
onRequest(long) - Method in class reactor.rx.subscription.support.WrappedSubscription
 
onSubscribe(Subscription) - Method in class reactor.core.processor.ReactorProcessor
 
onSubscribe(Subscription) - Method in class reactor.core.reactivestreams.SerializedSubscriber
 
onSubscribe(Subscription) - Method in class reactor.core.reactivestreams.SubscriberBarrier
 
onSubscribe(Subscription) - Method in class reactor.core.reactivestreams.SubscriberWithContext
 
onSubscribe(Subscription) - Method in class reactor.logback.AsyncAppender
 
onSubscribe(Subscription) - Method in class reactor.rx.action.Action
 
onSubscribe(Subscription) - Method in class reactor.rx.action.combination.CombineLatestAction.InnerSubscriber
 
onSubscribe(Subscription) - Method in class reactor.rx.action.combination.DynamicMergeAction
 
onSubscribe(Subscription) - Method in class reactor.rx.action.combination.FanInSubscription
 
onSubscribe(Subscription) - Method in class reactor.rx.action.combination.MergeAction.InnerSubscriber
 
onSubscribe(Subscription) - Method in class reactor.rx.action.combination.SwitchAction.SwitchSubscriber
 
onSubscribe(Subscription) - Method in class reactor.rx.action.combination.ZipAction.InnerSubscriber
 
onSubscribe(Subscription) - Method in class reactor.rx.action.CompositeAction
 
onSubscribe(Subscription) - Method in class reactor.rx.action.support.DefaultSubscriber
 
onSubscribe(Subscription) - Method in class reactor.rx.broadcast.Broadcaster
 
onSubscribe(Subscription) - Method in class reactor.rx.broadcast.SerializedBroadcaster
 
onSubscribe(Subscription) - Method in class reactor.rx.Promise
 
onSuccess(Consumer<O>) - Method in class reactor.rx.Promise
Assign a Consumer 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.
onWebsocket(HttpChannel<IN, OUT>) - Method in class reactor.io.net.http.HttpServer
 
onWebsocket(HttpChannel<IN, OUT>) - Method in class reactor.io.net.impl.netty.http.NettyHttpServer
 
op(MapStream.Operation) - Method in class reactor.rx.stream.MapStream.MutableSignal
 
op() - Method in class reactor.rx.stream.MapStream.Signal
 
OPTIONS - Static variable in class reactor.io.net.http.model.Method
 
options(ClientSocketOptions) - Method in class reactor.io.net.Spec.HttpClientSpec
Set the common ClientSocketOptions for connections made in this client.
options - Variable in class reactor.io.net.Spec.PeerSpec
 
options(ServerSocketOptions) - Method in class reactor.io.net.Spec.PeerSpec
Set the common ServerSocketOptions for channels made in this server.
options(ClientSocketOptions) - Method in class reactor.io.net.Spec.TcpClientSpec
Set the common ClientSocketOptions for connections made in this client.
or(Predicate<? super T>, Predicate<? super T>) - Static method in class reactor.fn.Predicates
Deprecated.
Returns a Predicate which evaluates to true if either this predicate or the provided predicate evaluate to true.
or(Stream<O>, E) - Static method in class reactor.groovy.ext.StreamExtensions
 
or(Stream<T>, Function<T, V>) - Static method in class reactor.groovy.ext.StreamExtensions
 
or(Promise<T>, Function<T, V>) - Static method in class reactor.groovy.ext.StreamExtensions
 
ORIGIN - Static variable in class reactor.bus.Event.Headers
The name of the origin header
ORIGIN - Static variable in interface reactor.io.net.http.model.HttpHeaders
The HTTP Origin header field name.
output() - Method in class reactor.rx.action.CompositeAction
 
override(Event<T>) - Method in class reactor.bus.Event
 

P

pair() - Method in class reactor.rx.stream.MapStream.Signal
 
pairFrom(Function<Tuple2<LEFT, RIGHT>, V>) - Static method in class reactor.fn.Functions
Deprecated.
Wrap a given Function that applies transformation to a Tuple2 into a PairFunction.
parallelRequest(long) - Method in class reactor.rx.action.combination.FanInSubscription
 
param(String) - Method in class reactor.io.net.http.HttpChannel
Read URI param from the given key
params() - Method in class reactor.io.net.http.HttpChannel
Read all URI params
ParkWaitStrategy - Class in reactor.core.dispatch.wait
 
ParkWaitStrategy() - Constructor for class reactor.core.dispatch.wait.ParkWaitStrategy
 
ParkWaitStrategy(long) - Constructor for class reactor.core.dispatch.wait.ParkWaitStrategy
 
parseInt(Buffer, int, int) - Static method in class reactor.io.buffer.Buffer
Very efficient method for parsing an Integer from the given Buffer range.
parseInt(Buffer) - Static method in class reactor.io.buffer.Buffer
Very efficient method for parsing an Integer from the given Buffer.
parseLong(Buffer, int, int) - Static method in class reactor.io.buffer.Buffer
Very efficient method for parsing a Long from the given Buffer range.
parseLong(Buffer) - Static method in class reactor.io.buffer.Buffer
Very efficient method for parsing a Long from the given Buffer.
PARTIAL_CONTENT - Static variable in class reactor.io.net.http.model.Status
206 Partial Content
partition() - Method in class reactor.rx.Stream
Re-route incoming values into a dynamically created Stream for each unique key evaluated by the {param keyMapper}.
partition(int) - Method in class reactor.rx.Stream
Re-route incoming values into a dynamically created Stream for each unique key evaluated by the {param keyMapper}.
PASS_THROUGH_CODEC - Static variable in class reactor.io.codec.StandardCodecs
 
PassThroughCodec<SRC> - Class in reactor.io.codec
A simple Codec that uses the source object as both input and output.
PassThroughCodec() - Constructor for class reactor.io.codec.PassThroughCodec
 
PassThroughFilter - Class in reactor.bus.filter
A Filter implementation that performs no filtering, returning the items as-is.
PassThroughFilter() - Constructor for class reactor.bus.filter.PassThroughFilter
 
PATCH - Static variable in class reactor.io.net.http.model.Method
 
Pausable - Interface in reactor.fn
 
pause() - Method in class reactor.bus.registry.CachableRegistration
 
pause() - Method in interface reactor.bus.registry.Registration
Pause this Registration.
pause() - Method in interface reactor.fn.Pausable
Pause this Pausable.
pause() - Method in class reactor.fn.timer.HashWheelTimer.TimerPausable
Pause the current Regisration
PAYMENT_REQUIRED - Static variable in class reactor.io.net.http.model.Status
402 Payment Required
peek() - Method in class reactor.core.queue.internal.MpscLinkedQueue
 
peek() - Method in class reactor.io.queue.PersistentQueue
 
peek() - Method in class reactor.rx.action.combination.FanInSubscription
 
PeerSpec() - Constructor for class reactor.io.net.Spec.PeerSpec
 
PENDING_UPDATER - Static variable in class reactor.core.reactivestreams.SubscriptionWithContext
 
PENDING_UPDATER - Static variable in class reactor.rx.subscription.PushSubscription
 
pendingRequestSignals - Variable in class reactor.rx.subscription.PushSubscription
 
pendingRequestSignals() - Method in class reactor.rx.subscription.PushSubscription
 
period(long) - Static method in class reactor.rx.Streams
Build a Stream that will emit ever increasing counter from 0 after on each period from the subscribe call.
period(Timer, long) - Static method in class reactor.rx.Streams
Build a Stream that will emit ever increasing counter from 0 after on each period from the subscribe call.
period(long, long) - Static method in class reactor.rx.Streams
Build a Stream that will emit ever increasing counter from 0 after the time delay on each period.
period(Timer, long, long) - Static method in class reactor.rx.Streams
Build a Stream that will emit ever increasing counter from 0 after the time delay on each period.
period(long, TimeUnit) - Static method in class reactor.rx.Streams
Build a Stream that will emit ever increasing counter from 0 after the subscribe call on each period.
period(Timer, long, TimeUnit) - Static method in class reactor.rx.Streams
Build a Stream that will emit ever increasing counter from 0 after the subscribe call on each period.
period(long, long, TimeUnit) - Static method in class reactor.rx.Streams
Build a Stream that will emit ever increasing counter from 0 after the subscribe call on each period.
period(Timer, long, long, TimeUnit) - Static method in class reactor.rx.Streams
Build a Stream that will emit ever increasing counter from 0 after the time delay on each period.
PeriodicTimerStream - Class in reactor.rx.stream
A Stream that emits 0 after an initial delay and ever incrementing long counter if the period argument is specified.
PeriodicTimerStream(long, long, TimeUnit, Timer) - Constructor for class reactor.rx.stream.PeriodicTimerStream
 
persistentMap(String) - Static method in class reactor.rx.IOStreams
A Persistent Map is a MapStream that fulfill both the Map and the Stream contract.
persistentMap(String, boolean) - Static method in class reactor.rx.IOStreams
A Persistent Map is a MapStream that fulfill both the Map and the Stream contract.
persistentMapReader(String) - Static method in class reactor.rx.IOStreams
A Persistent Map is a MapStream that fulfill both the Map and the Stream contract.
PersistentQueue<T> - Class in reactor.io.queue
A PersistentQueue is a Queue implementation that delegates the actual storage of the elements in the queue to a QueuePersistor.
PersistentQueue(QueuePersistor<T>) - Constructor for class reactor.io.queue.PersistentQueue
Create a PersistentQueue using the given QueuePersistor.
PersistentQueueSpec<T> - Class in reactor.io.queue.spec
Helper spec to create a PersistentQueue instance.
PersistentQueueSpec() - Constructor for class reactor.io.queue.spec.PersistentQueueSpec
 
PING - Static variable in class reactor.io.net.ReactorClient
 
pipelineConfigurer() - Method in class reactor.io.net.impl.netty.NettyClientSocketOptions
 
pipelineConfigurer(Consumer<ChannelPipeline>) - Method in class reactor.io.net.impl.netty.NettyClientSocketOptions
 
pipelineConfigurer() - Method in class reactor.io.net.impl.netty.NettyServerSocketOptions
 
pipelineConfigurer(Consumer<ChannelPipeline>) - Method in class reactor.io.net.impl.netty.NettyServerSocketOptions
 
PlatformDependent - Class in reactor.core.internal
Borrowed from Netty project which itself borrows from JCTools and various other projects.
PlatformDependent() - Constructor for class reactor.core.internal.PlatformDependent
 
poll() - Method in class reactor.core.queue.CompletableBlockingQueue
 
poll(long, TimeUnit) - Method in class reactor.core.queue.CompletableBlockingQueue
 
poll() - Method in class reactor.core.queue.internal.MpscLinkedQueue
 
poll() - Method in class reactor.io.queue.PersistentQueue
 
poll() - Method in class reactor.rx.Promise
Block the calling thread, waiting for the completion of this Promise.
poll(long, TimeUnit) - Method in class reactor.rx.Promise
Block the calling thread for the specified time, waiting for the completion of this Promise.
poolSize() - Method in class reactor.core.dispatch.MultiThreadDispatcher
 
PORT_RANGE_MAX - Static variable in class reactor.io.net.tcp.support.SocketUtils
The default maximum value for port ranges used when finding an available socket port.
PORT_RANGE_MIN - Static variable in class reactor.io.net.tcp.support.SocketUtils
The default minimum value for port ranges used when finding an available socket port.
position() - Method in class reactor.io.buffer.Buffer
Provides the current position in the internal ByteBuffer.
position(int) - Method in class reactor.io.buffer.Buffer
Sets this buffer's position.
post(String, ReactorChannelHandler<IN, OUT, HttpChannel<IN, OUT>>) - Method in class reactor.io.net.http.HttpClient
HTTP POST the passed URL.
post(String, ReactorChannelHandler<IN, OUT, HttpChannel<IN, OUT>>) - Method in class reactor.io.net.http.HttpServer
Listen for HTTP POST on the passed path to be used as a routing condition.
POST - Static variable in class reactor.io.net.http.model.Method
 
post(String) - Static method in class reactor.io.net.NetSelectors
postRead(ChannelHandlerContext, Object) - Method in class reactor.io.net.impl.netty.http.NettyHttpClientHandler
 
postRead(ChannelHandlerContext, Object) - Method in class reactor.io.net.impl.netty.http.NettyHttpServerHandler
 
postRead(ChannelHandlerContext, Object) - Method in class reactor.io.net.impl.netty.http.NettyHttpWSClientHandler
 
PRAGMA - Static variable in interface reactor.io.net.http.model.Headers
The HTTP Pragma header field name.
PRECONDITION_FAILED - Static variable in class reactor.io.net.http.model.Status
412 Precondition Failed
PRECONDITION_REQUIRED - Static variable in class reactor.io.net.http.model.Status
428 Precondition Required (RFC6585)
predicate(Predicate<Object>) - Static method in class reactor.bus.selector.Selectors
Creates a Selector based on the given Predicate.
Predicate<T> - Interface in reactor.fn
Determines if the input object matches some criteria.
Predicates - Class in reactor.fn
Deprecated.
Predicates() - Constructor for class reactor.fn.Predicates
Deprecated.
 
PredicateSelector - Class in reactor.bus.selector
Implementation of Selector that delegates the work of matching an object to the given Predicate.
PredicateSelector(Predicate<Object>) - Constructor for class reactor.bus.selector.PredicateSelector
 
predicateSelector(Predicate<Object>) - Static method in class reactor.bus.selector.PredicateSelector
Creates a Selector based on the given Predicate.
prefetch() - Method in class reactor.io.net.config.CommonSocketOptions
Gets the prefetch maximum in-flight value
prefetch(long) - Method in class reactor.io.net.config.CommonSocketOptions
Set the Consuming capacity along with eventual flushing strategy each given prefetch iteration.
prepare(Object) - Method in class reactor.bus.EventBus
Create an optimized path for publishing notifications to the given key.
prepare() - Static method in class reactor.rx.Promises
Create a synchronous Promise.
prepare(Environment) - Static method in class reactor.rx.Promises
Create a Promise.
prepend(Buffer) - Method in class reactor.io.buffer.Buffer
Prepend the given Buffer to this Buffer.
prepend(String) - Method in class reactor.io.buffer.Buffer
Prepend the given String to this Buffer.
prepend(byte[]) - Method in class reactor.io.buffer.Buffer
Prepend the given byte[] array to this Buffer.
prepend(ByteBuffer) - Method in class reactor.io.buffer.Buffer
Prepend the given ByteBuffer to this Buffer.
prepend(byte) - Method in class reactor.io.buffer.Buffer
Prepend the given byte to this Buffer.
prepend(char) - Method in class reactor.io.buffer.Buffer
Prepend the given char to this existing Buffer.
prepend(short) - Method in class reactor.io.buffer.Buffer
Prepend the given short to this Buffer.
prepend(int) - Method in class reactor.io.buffer.Buffer
Prepend the given int to this Buffer.
prepend(long) - Method in class reactor.io.buffer.Buffer
Prepend the given long to this Buffer.
previous(V) - Method in class reactor.rx.stream.MapStream.MutableSignal
 
previous() - Method in class reactor.rx.stream.MapStream.Signal
 
process(Processor<O, E>) - Method in class reactor.rx.Stream
Create a Tap that maintains a reference to the last value seen by this Stream.
PROCESSING - Static variable in class reactor.io.net.http.model.Status
102 Processing (WebDAV, RFC2518)
processor(String, Processor<?, Event>) - Method in class reactor.groovy.config.ReactorBuilder
 
processor(Selector, Processor<?, Event>) - Method in class reactor.groovy.config.ReactorBuilder
 
PROCESSORS - Static variable in class reactor.Environment
The number of processors available to the runtime
Promise<O> - Class in reactor.rx
A Promise is a stateful event container that accepts a single value or error.
Promise() - Constructor for class reactor.rx.Promise
Creates a new unfulfilled promise.
Promise(Dispatcher, Environment) - Constructor for class reactor.rx.Promise
Creates a new unfulfilled promise.
Promise(O, Dispatcher, Environment) - Constructor for class reactor.rx.Promise
Creates a new promise that has been fulfilled with the given value.
Promise(Throwable, Dispatcher, Environment) - Constructor for class reactor.rx.Promise
Creates a new promise that has failed with the given error.
Promise.FinalState - Enum in reactor.rx
 
Promises - Class in reactor.rx
Helper methods for creating Promise instances.
Promises() - Constructor for class reactor.rx.Promises
 
PropertiesConfigurationReader - Class in reactor.core.config
A ConfigurationReader that reads the configuration from properties files and System properties.
PropertiesConfigurationReader() - Constructor for class reactor.core.config.PropertiesConfigurationReader
Creates a new PropertiesConfigurationReader that, by default, will load its configuration from META-INF/reactor/default.properties.
PropertiesConfigurationReader(String) - Constructor for class reactor.core.config.PropertiesConfigurationReader
 
ProtobufCodec<IN,OUT> - Class in reactor.io.codec.protobuf
 
ProtobufCodec() - Constructor for class reactor.io.codec.protobuf.ProtobufCodec
 
ProtobufCodec(boolean) - Constructor for class reactor.io.codec.protobuf.ProtobufCodec
 
protocol() - Method in class reactor.io.net.http.HttpChannel
 
protocol - Variable in class reactor.io.net.http.HttpSelector
 
Protocol - Enum in reactor.io.net.http.model
A Model representation of supported HTTP Protocols
protocol() - Method in class reactor.io.net.impl.netty.http.NettyHttpChannel
 
protocolFamily() - Method in class reactor.io.net.config.ServerSocketOptions
Returns the configured protocol family for the socket.
protocolFamily(ProtocolFamily) - Method in class reactor.io.net.config.ServerSocketOptions
Configures the protocol family for the socket.
PROXY_AUTHENTICATE - Static variable in interface reactor.io.net.http.model.ResponseHeaders
The HTTP Proxy-Authenticate header field name.
PROXY_AUTHENTICATION_REQUIRED - Static variable in class reactor.io.net.http.model.Status
407 Proxy Authentication Required
PROXY_AUTHORIZATION - Static variable in interface reactor.io.net.http.model.HttpHeaders
The HTTP Proxy-Authorization header field name.
publisher - Variable in class reactor.rx.subscription.PushSubscription
 
PublisherFactory - Class in reactor.core.reactivestreams
A Reactive Streams Publisher factory which callbacks on start, request and shutdown The Publisher will directly forward all the signals passed to the subscribers and complete when onComplete is called.
PublisherFactory() - Constructor for class reactor.core.reactivestreams.PublisherFactory
 
PublisherFactory.PrematureCompleteException - Exception in reactor.core.reactivestreams
 
PublisherStream<T> - Class in reactor.rx.stream
A Publisher wrapper that takes care of lazy subscribing.
PublisherStream(Publisher<T>) - Constructor for class reactor.rx.stream.PublisherStream
 
pull(String) - Method in class reactor.io.net.impl.zmq.tcp.ZeroMQ
 
push(String) - Method in class reactor.io.net.impl.zmq.tcp.ZeroMQ
 
PushSubscription<O> - Class in reactor.rx.subscription
Relationship between a Stream (Publisher) and a Subscriber.
PushSubscription(Stream<O>, Subscriber<? super O>) - Constructor for class reactor.rx.subscription.PushSubscription
 
pushSubscription - Variable in class reactor.rx.subscription.support.WrappedSubscription
 
put(String, ReactorChannelHandler<IN, OUT, HttpChannel<IN, OUT>>) - Method in class reactor.io.net.http.HttpClient
HTTP PUT the passed URL.
put(String, ReactorChannelHandler<IN, OUT, HttpChannel<IN, OUT>>) - Method in class reactor.io.net.http.HttpServer
Listen for HTTP PUT on the passed path to be used as a routing condition.
PUT - Static variable in class reactor.io.net.http.model.Method
 
put(String) - Static method in class reactor.io.net.NetSelectors
put(K, V) - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
put(K, V) - Method in class reactor.rx.stream.io.ChronicleStream
 
putAll(Map<? extends K, ? extends V>) - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
putAll(Map<? extends K, ? extends V>) - Method in class reactor.rx.stream.io.ChronicleStream
 
putAt(String, EventBus) - Method in class reactor.groovy.config.GroovyEnvironment
 

Q

queueLoggingEvent(ILoggingEvent) - Method in class reactor.logback.AsyncAppender
 
queueLoggingEvent(ILoggingEvent) - Method in class reactor.logback.DurableAsyncAppender
 
QueuePersistor<T> - Interface in reactor.io.queue
Implementations of this interface are responsible for persisting the elements of a PersistentQueue.

R

R(String) - Static method in class reactor.bus.selector.Selectors
A short-hand alias for Selectors.regex(String).
random() - Static method in class reactor.core.support.UUIDUtils
Create a new random UUID.
randomEventRouting() - Method in class reactor.bus.spec.EventRoutingComponentSpec
Configures the component's EventRouter to route events to one consumer that's randomly selected from that matching consumers
RandomFilter - Class in reactor.bus.filter
A Filter implementation that returns a single, randomly selected item.
RandomFilter() - Constructor for class reactor.bus.filter.RandomFilter
 
RANGE - Static variable in interface reactor.io.net.http.model.HttpHeaders
The HTTP Range header field name.
range(long, long) - Static method in class reactor.rx.Streams
Build a Stream that will only emit a sequence of longs within the specified range and then complete.
RangeStream - Class in reactor.rx.stream
A Stream that emits N Long from the inclusive start value defined to the inclusive end and then complete.
RangeStream() - Constructor for class reactor.rx.stream.RangeStream
 
rawData(boolean) - Method in class reactor.io.net.Spec.PeerSpec
Bypass any Reactor Buffer encoding for received data
rawData(boolean) - Method in class reactor.io.net.Spec.TcpClientSpec
Bypass any Reactor Buffer encoding for received data
rcvbuf() - Method in class reactor.io.net.config.CommonSocketOptions
Gets the configured SO_RCVBUF (receive buffer) size
rcvbuf(int) - Method in class reactor.io.net.config.CommonSocketOptions
Sets the SO_RCVBUF (receive buffer) size
react(EventBus, Selector<K>, Closure) - Static method in class reactor.groovy.ext.BusExtensions
 
react(EventBus, String, Closure) - Static method in class reactor.groovy.ext.BusExtensions
 
ReactiveSubscription<O> - Class in reactor.rx.subscription
Relationship between a Stream (Publisher) and a Subscriber.
ReactiveSubscription(Stream<O>, Subscriber<? super O>) - Constructor for class reactor.rx.subscription.ReactiveSubscription
 
ReactiveSubscription(Stream<O>, Subscriber<? super O>, CompletableQueue<O>) - Constructor for class reactor.rx.subscription.ReactiveSubscription
 
reactor - package reactor
 
reactor(Closure) - Method in class reactor.groovy.config.GroovyEnvironment
 
reactor(String, Closure) - Method in class reactor.groovy.config.GroovyEnvironment
 
reactor(String) - Method in class reactor.groovy.config.GroovyEnvironment
 
reactor(String, EventBus) - Method in class reactor.groovy.config.GroovyEnvironment
 
reactor(Closure) - Method in class reactor.groovy.config.ReactorBuilder
 
reactor(String, Closure) - Method in class reactor.groovy.config.ReactorBuilder
 
reactor.alloc - package reactor.alloc
Pooling provides lower GC requirements by re-using components.
reactor.bus - package reactor.bus
Hold the required abstraction to enable Event Driven Programming with Reactor.
reactor.bus.filter - package reactor.bus.filter
Filters eliminate components from a list based on a predicate.
reactor.bus.publisher - package reactor.bus.publisher
 
reactor.bus.registry - package reactor.bus.registry
Registries provide a common way to retrieve items registered using a Selector.
reactor.bus.routing - package reactor.bus.routing
Event routing means sending a given Event to the correct Consumers.
reactor.bus.selector - package reactor.bus.selector
Selectors provide a way to register components to react to given key data.
reactor.bus.spec - package reactor.bus.spec
Specs help create Reactors by providing a fluent API to specify common options.
reactor.bus.support - package reactor.bus.support
 
reactor.bus.timer - package reactor.bus.timer
 
reactor.core - package reactor.core
Core components of the Reactor framework.
reactor.core.config - package reactor.core.config
Components to facilitate flexible configuration of the Reactor Environment.
reactor.core.dispatch - package 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.dispatch.wait - package reactor.core.dispatch.wait
 
reactor.core.internal - package reactor.core.internal
Core components of the Reactor framework.
reactor.core.processor - package reactor.core.processor
This package offers a suite of asynchronous Processor with backpressure support.
reactor.core.processor.util - package reactor.core.processor.util
 
reactor.core.queue - package reactor.core.queue
Queue implementations that provide completable states or lock-free queue
reactor.core.queue.internal - package reactor.core.queue.internal
 
reactor.core.reactivestreams - package reactor.core.reactivestreams
 
reactor.core.support - package reactor.core.support
 
reactor.fn - package reactor.fn
This package contains the foundational abstractions on which Reactor's functional and reactive components are built.
reactor.fn.support - package reactor.fn.support
 
reactor.fn.timer - package reactor.fn.timer
 
reactor.fn.tuple - package reactor.fn.tuple
Tuples provide a type-safe way to specify multiple parameters.
reactor.groovy.config - package reactor.groovy.config
 
reactor.groovy.ext - package reactor.groovy.ext
 
reactor.groovy.support - package reactor.groovy.support
 
reactor.io - package reactor.io
Buffer-handling and other IO-related components.
reactor.io.buffer - package reactor.io.buffer
 
reactor.io.codec - package reactor.io.codec
Components to handle encoding and decoding of objects into Buffers.
reactor.io.codec.compress - package reactor.io.codec.compress
 
reactor.io.codec.json - package reactor.io.codec.json
Encoding and decoding using the JSON format.
reactor.io.codec.kryo - package reactor.io.codec.kryo
 
reactor.io.codec.protobuf - package reactor.io.codec.protobuf
 
reactor.io.net - package 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 - package reactor.io.net.codec.syslog
Decoding using the syslog format.
reactor.io.net.config - package reactor.io.net.config
Configuration of the various TCP parameters for clients and servers.
reactor.io.net.http - package reactor.io.net.http
Components for writing HTTP-based clients and servers using Reactor abstractions.
reactor.io.net.http.model - package reactor.io.net.http.model
 
reactor.io.net.impl.netty - package reactor.io.net.impl.netty
Implementations of the various TCP abstractions based on Netty.
reactor.io.net.impl.netty.http - package reactor.io.net.impl.netty.http
 
reactor.io.net.impl.netty.tcp - package reactor.io.net.impl.netty.tcp
 
reactor.io.net.impl.netty.udp - package reactor.io.net.impl.netty.udp
 
reactor.io.net.impl.zmq - package reactor.io.net.impl.zmq
 
reactor.io.net.impl.zmq.tcp - package reactor.io.net.impl.zmq.tcp
 
reactor.io.net.tcp - package reactor.io.net.tcp
Components for writing TCP-based clients and servers using Reactor abstractions.
reactor.io.net.tcp.ssl - package reactor.io.net.tcp.ssl
Support classes for Reactor's TCP SSL support.
reactor.io.net.tcp.support - package reactor.io.net.tcp.support
 
reactor.io.net.udp - package reactor.io.net.udp
 
reactor.io.queue - package reactor.io.queue
Queue implementations that provide a persistence strategy for making sure items in the Queue aren't lost.
reactor.io.queue.spec - package reactor.io.queue.spec
Specs provide a simple fluent DSL for creating PersistentQueues by specifying common options.
reactor.logback - package reactor.logback
 
reactor.rx - package reactor.rx
Streams are reactive components derived from Reactive Extensions and implementing Reactive Streams specification.
reactor.rx.action - package reactor.rx.action
Actions are Reactive Streams components derived from Reactive Extensions and beyond.
reactor.rx.action.aggregation - package reactor.rx.action.aggregation
 
reactor.rx.action.combination - package reactor.rx.action.combination
 
reactor.rx.action.conditional - package reactor.rx.action.conditional
 
reactor.rx.action.control - package reactor.rx.action.control
 
reactor.rx.action.error - package reactor.rx.action.error
 
reactor.rx.action.filter - package reactor.rx.action.filter
 
reactor.rx.action.metrics - package reactor.rx.action.metrics
 
reactor.rx.action.pair - package reactor.rx.action.pair
 
reactor.rx.action.passive - package reactor.rx.action.passive
 
reactor.rx.action.support - package reactor.rx.action.support
 
reactor.rx.action.terminal - package reactor.rx.action.terminal
 
reactor.rx.action.transformation - package reactor.rx.action.transformation
 
reactor.rx.broadcast - package reactor.rx.broadcast
Broadcasters are akin to Reactive Extensions Subject.
reactor.rx.stream - package reactor.rx.stream
 
reactor.rx.stream.io - package reactor.rx.stream.io
Stream implementations that provide for IO access, for instance read/read-write persisting streams
reactor.rx.subscription - package reactor.rx.subscription
 
reactor.rx.subscription.support - package reactor.rx.subscription.support
 
reactorBuilder(String) - Method in class reactor.groovy.config.GroovyEnvironment
 
reactorBuilder(String, ReactorBuilder) - Method in class reactor.groovy.config.GroovyEnvironment
 
ReactorBuilder - Class in reactor.groovy.config
 
ReactorBuilder(String, Map<String, ReactorBuilder>) - Constructor for class reactor.groovy.config.ReactorBuilder
 
ReactorBuilder(String, Map<String, ReactorBuilder>, EventBus) - Constructor for class reactor.groovy.config.ReactorBuilder
 
ReactorBuilder.NestedReactorBuilder - Class in reactor.groovy.config
 
ReactorBuilder.SelectorProcessor - Class in reactor.groovy.config
 
reactorBuildersByExtension(String) - Method in class reactor.groovy.config.GroovyEnvironment
 
ReactorChannel<IN,OUT> - Interface in reactor.io.net
Channel is a virtual connection that often matches with a Socket or a Channel (e.g.
ReactorChannel.ConsumerSpec - Interface in reactor.io.net
Spec class for assigning multiple event handlers on a channel.
ReactorChannelHandler<IN,OUT,CONN extends ReactorChannel<IN,OUT>> - Interface in reactor.io.net
A ReactorChannel callback that is attached on ReactorPeer or ReactorClient initialization and receives all connected ReactorChannel.
ReactorClient<IN,OUT,CONN extends ChannelStream<IN,OUT>> - Class in reactor.io.net
A network-aware client that will publish its connection once available to the ReactorChannelHandler passed.
ReactorClient(Environment, Dispatcher, Codec<Buffer, IN, OUT>, long) - Constructor for class reactor.io.net.ReactorClient
 
ReactorConfiguration - Class in reactor.core.config
An encapsulation of configuration for Reactor
ReactorConfiguration(List<DispatcherConfiguration>, String, Properties) - Constructor for class reactor.core.config.ReactorConfiguration
 
ReactorFatalException - Exception in reactor.core.support
an exception that should stop producing more data
ReactorPeer<IN,OUT,CONN extends ChannelStream<IN,OUT>> - Class in reactor.io.net
Abstract base class that implements common functionality shared by clients and servers.
ReactorPeer(Environment, Dispatcher, Codec<Buffer, IN, OUT>) - Constructor for class reactor.io.net.ReactorPeer
 
ReactorPeer(Environment, Dispatcher, Codec<Buffer, IN, OUT>, long) - Constructor for class reactor.io.net.ReactorPeer
 
ReactorProcessor<IN,OUT> - Class in reactor.core.processor
A base processor
ReactorProcessor(boolean) - Constructor for class reactor.core.processor.ReactorProcessor
 
ReactorScriptWrapper - Class in reactor.groovy.config
 
ReactorScriptWrapper() - Constructor for class reactor.groovy.config.ReactorScriptWrapper
 
ReactorStaticExtensions - Class in reactor.groovy.ext
 
ReactorStaticExtensions() - Constructor for class reactor.groovy.ext.ReactorStaticExtensions
 
read() - Method in interface reactor.core.config.ConfigurationReader
Reads the configuration
read() - Method in class reactor.core.config.PropertiesConfigurationReader
 
read() - Method in class reactor.groovy.config.EnvironmentBuilder
 
read() - Method in class reactor.io.buffer.Buffer
Read a single byte from the underlying ByteBuffer.
read(byte[]) - Method in class reactor.io.buffer.Buffer
Read at least b.length bytes from the underlying ByteBuffer.
read(ByteBuffer) - Method in class reactor.io.buffer.Buffer
 
read(ByteBuffer) - Method in class reactor.io.IO.FileContext
 
read(ReadableByteChannel) - Static method in class reactor.io.IO
Transform a ReadableByteChannel into a Publisher of Buffer with a max chunk size of Buffer.SMALL_BUFFER_SIZE.
read(ReadableByteChannel, int) - Static method in class reactor.io.IO
Transform a ReadableByteChannel into a Publisher of Buffer with a max chunk size of chunkSize.
ReadableHeaders - Interface in reactor.io.net.http.model
 
readChar() - Method in class reactor.io.buffer.Buffer
Read the next char from the underlying ByteBuffer.
readDouble() - Method in class reactor.io.buffer.Buffer
Read the next double from the underlying ByteBuffer.
reader() - Method in class reactor.io.queue.ChronicleQueuePersistor
 
readFile(Path) - Static method in class reactor.io.IO
Read bytes as Buffer from file specified by the Path argument with a max chunk size of Buffer.SMALL_BUFFER_SIZE.
readFile(Path, int) - Static method in class reactor.io.IO
Read bytes as Buffer from file specified by the Path argument with a max chunkSize Complete when channel read is negative.
readFile(String) - Static method in class reactor.io.IO
Read bytes as Buffer from file specified by the Path argument with a max chunk size of Buffer.SMALL_BUFFER_SIZE.
readFile(String, int) - Static method in class reactor.io.IO
Read bytes as Buffer from file specified by the Path argument with a max chunkSize Complete when channel read is negative.
readFloat() - Method in class reactor.io.buffer.Buffer
Read the next float from the underlying ByteBuffer.
readIdle(long, Consumer<Void>) - Method in interface reactor.io.net.ReactorChannel.ConsumerSpec
Assign a Runnable to be invoked when reads have become idle for the given timeout.
readInt() - Method in class reactor.io.buffer.Buffer
Read the next int from the underlying ByteBuffer.
readLong() - Method in class reactor.io.buffer.Buffer
Read the next long from the underlying ByteBuffer.
readOnly() - Method in class reactor.bus.Event.Headers
Get the headers as a read-only version
readShort() - Method in class reactor.io.buffer.Buffer
Read the next short from the underlying ByteBuffer.
readType(Buffer) - Method in class reactor.io.codec.SerializationCodec
 
ready() - Method in class reactor.fn.timer.HashWheelTimer.TimerPausable
Check whether the current Registration is ready for execution
ready(Environment, Dispatcher) - Static method in class reactor.rx.Promises
Create a Promise.
reason() - Method in class reactor.rx.Promise
Return the error (if any) that has completed this Promise.
receive(Selector, Function<T, V>) - Method in class reactor.bus.EventBus
Assign a Function to receive an Event and produce a reply of the given type.
Reconnect - Interface in reactor.io.net
Implementations of this interface will be instantiated by a Supplier to provide information to the TcpClient whether or not to attempt to reconnect a broken connection.
reconnect(InetSocketAddress, int) - Method in interface reactor.io.net.Reconnect
Provide an InetSocketAddress to which a reconnection attempt should be made.
recover(Class<? extends Throwable>, Subscriber<Object>) - Method in class reactor.rx.Stream
Create a new Stream which will re-subscribe its oldest parent-child stream pair if the exception is of the given type.
Recyclable - Interface in reactor.core.support
A simple interface that marks an object as being recyclable.
RecyclableNumber - Class in reactor.alloc
 
RecyclableNumber() - Constructor for class reactor.alloc.RecyclableNumber
 
RecyclableString - Class in reactor.alloc
 
RecyclableString() - Constructor for class reactor.alloc.RecyclableString
 
recycle() - Method in class reactor.alloc.RecyclableNumber
 
recycle() - Method in class reactor.alloc.RecyclableString
 
recycle() - Method in class reactor.bus.Event
 
recycle() - Method in class reactor.core.dispatch.AbstractLifecycleDispatcher.Task
 
recycle() - Method in interface reactor.core.support.Recyclable
Free any internal resources and reset the state of the object to enable reuse.
recycle() - Method in class reactor.io.buffer.Buffer
 
recycle() - Method in class reactor.rx.action.Action
 
recycle() - Method in class reactor.rx.broadcast.Broadcaster
 
reduce(BiFunction<O, O, O>) - Method in class reactor.rx.Stream
Reduce the values passing through this Stream into an object T.
reduce(A, BiFunction<A, ? super O, A>) - Method in class reactor.rx.Stream
Reduce the values passing through this Stream into an object A.
reduceByKey(Publisher<? extends Tuple2<K, V>>, BiFunction<V, V, V>) - Static method in class reactor.groovy.ext.StreamExtensions
 
reduceByKey(Publisher<Tuple2<KEY, VALUE>>, BiFunction<VALUE, VALUE, VALUE>) - Static method in class reactor.rx.BiStreams
 
reduceByKey(Publisher<Tuple2<KEY, VALUE>>, MapStream<KEY, VALUE>, BiFunction<VALUE, VALUE, VALUE>) - Static method in class reactor.rx.BiStreams
 
reduceByKey(Publisher<Tuple2<KEY, VALUE>>, Map<KEY, VALUE>, Publisher<? extends MapStream.Signal<KEY, VALUE>>, BiFunction<VALUE, VALUE, VALUE>) - Static method in class reactor.rx.BiStreams
 
ReduceByKeyAction<K,V> - Class in reactor.rx.action.pair
 
ReduceByKeyAction(BiFunction<? super V, ? super V, V>, MapStream<K, V>) - Constructor for class reactor.rx.action.pair.ReduceByKeyAction
 
ReduceByKeyAction(BiFunction<? super V, ? super V, V>, Map<K, V>, Publisher<? extends MapStream.Signal<K, V>>) - Constructor for class reactor.rx.action.pair.ReduceByKeyAction
 
reduceByKeyOn(Publisher<Tuple2<KEY, VALUE>>, Map<KEY, VALUE>, Publisher<? extends MapStream.Signal<KEY, VALUE>>, BiFunction<VALUE, VALUE, VALUE>) - Static method in class reactor.rx.BiStreams
 
Reference<T extends Recyclable> - Interface in reactor.alloc
A Reference provides access to and metadata about a poolable object.
ReferenceCountingAllocator<T extends Recyclable> - Class in reactor.alloc
An implementation of Allocator that uses reference counting to determine when an object should be recycled and placed back into the pool to be reused.
ReferenceCountingAllocator(Supplier<T>) - Constructor for class reactor.alloc.ReferenceCountingAllocator
 
ReferenceCountingAllocator(int, Supplier<T>) - Constructor for class reactor.alloc.ReferenceCountingAllocator
 
REFERER - Static variable in interface reactor.io.net.http.model.HttpHeaders
The HTTP Referer header field name.
refMap() - Method in class reactor.io.queue.InMemoryQueuePersistor
 
regex(String) - Static method in class reactor.bus.selector.Selectors
Creates a Selector based on the given regular expression.
RegexSelector - Class in reactor.bus.selector
A Selector implementation based on the given regular expression.
RegexSelector(String) - Constructor for class reactor.bus.selector.RegexSelector
Create a Selector when the given regex pattern.
regexSelector(String) - Static method in class reactor.bus.selector.RegexSelector
Creates a Selector based on the given regular expression.
register(Selector<K>, V) - Method in class reactor.bus.registry.CachingRegistry
 
register(Selector<K>, V) - Method in interface reactor.bus.registry.Registry
Assign the given Selector with the given object.
register(Selector<K>, V) - Method in class reactor.bus.registry.SimpleCachingRegistry
 
Registration<K,V> - Interface in reactor.bus.registry
A Registration represents an object that has been registered with a Registry.
Registries - Class in reactor.bus.registry
 
Registries() - Constructor for class reactor.bus.registry.Registries
 
Registry<K,V> - Interface in reactor.bus.registry
Implementations of this interface manage a registry of objects that works sort of like a Map, except Registries don't use simple keys, they use Selectors to map their objects.
rehydrate(ReactorBuilder) - Method in class reactor.groovy.config.ReactorBuilder
 
release() - Method in class reactor.alloc.AbstractReference
 
release(int) - Method in class reactor.alloc.AbstractReference
 
release(List<Reference<T>>) - Method in interface reactor.alloc.Allocator
Efficiently release a batch of References all at once.
release() - Method in interface reactor.alloc.Reference
Decrease the reference count by 1.
release(int) - Method in interface reactor.alloc.Reference
Decrease the reference count by incr amount.
release(List<Reference<T>>) - Method in class reactor.alloc.ReferenceCountingAllocator
 
release(List<Reference<Buffer>>) - Method in class reactor.io.buffer.BufferAllocator
 
remaining() - Method in class reactor.io.buffer.Buffer
How many bytes available in this Buffer.
remainingSlots() - Method in class reactor.core.dispatch.MpscDispatcher
 
remainingSlots() - Method in class reactor.core.dispatch.RingBufferDispatcher
 
remainingSlots() - Method in class reactor.core.dispatch.SynchronousDispatcher
 
remainingSlots() - Method in class reactor.core.dispatch.TailRecurseDispatcher
 
remainingSlots() - Method in class reactor.core.dispatch.ThreadPoolExecutorDispatcher
 
remainingSlots() - Method in class reactor.core.dispatch.TraceableDelegatingDispatcher
 
remainingSlots() - Method in class reactor.core.dispatch.WorkQueueDispatcher
 
remainingSlots() - Method in interface reactor.core.Dispatcher
Request the remaining capacity for the underlying shared state structure.
remoteAddress() - Method in class reactor.io.net.impl.netty.http.NettyHttpChannel
 
remoteAddress() - Method in class reactor.io.net.impl.netty.NettyChannelStream
 
remoteAddress() - Method in class reactor.io.net.impl.zmq.ZeroMQChannelStream
 
remoteAddress() - Method in interface reactor.io.net.ReactorChannel
Get the address of the remote peer.
remove() - Method in class reactor.core.queue.internal.MpscLinkedQueue
 
remove(Object) - Method in class reactor.core.queue.internal.MpscLinkedQueue
 
remove(String) - Method in interface reactor.io.net.http.model.WritableHeaders
 
remove(String) - Method in class reactor.io.net.impl.netty.http.NettyHttpHeaders
 
remove(String) - Method in class reactor.io.net.impl.netty.http.NettyHttpResponseHeaders
 
remove() - Method in class reactor.io.queue.ChronicleQueuePersistor
 
remove() - Method in class reactor.io.queue.InMemoryQueuePersistor
 
remove() - Method in interface reactor.io.queue.QueuePersistor
Remove the oldest item from the persistence queue.
remove(Object) - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
remove(Object) - Method in class reactor.rx.stream.io.ChronicleStream
 
remove(PushSubscription<O>) - Method in class reactor.rx.subscription.FanOutSubscription
 
removeAll(Collection<?>) - Method in class reactor.core.queue.internal.MpscLinkedQueue
 
removeCachedDispatchers(String) - Method in class reactor.Environment
Remove the dispatcherFactory to the environment keyed as the given name.
removeDispatcher(String) - Method in class reactor.Environment
Removes the Dispatcher, stored using the given name from the environment.
removeTransferEncodingChunked() - Method in interface reactor.io.net.http.model.WritableHeaders
 
removeTransferEncodingChunked() - Method in class reactor.io.net.impl.netty.http.NettyHttpHeaders
 
removeTransferEncodingChunked() - Method in class reactor.io.net.impl.netty.http.NettyHttpResponseHeaders
 
repeat() - Method in class reactor.rx.Stream
Create a new Stream which will keep re-subscribing its oldest parent-child stream pair on complete.
repeat(int) - Method in class reactor.rx.Stream
Create a new Stream which will keep re-subscribing its oldest parent-child stream pair on complete.
RepeatAction<T> - Class in reactor.rx.action.control
 
RepeatAction(Dispatcher, int, Publisher<? extends T>) - Constructor for class reactor.rx.action.control.RepeatAction
 
repeatWhen(Function<? super Stream<? extends Long>, ? extends Publisher<?>>) - Method in class reactor.rx.Stream
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.
RepeatWhenAction<T> - Class in reactor.rx.action.control
 
RepeatWhenAction(Dispatcher, Function<? super Stream<? extends Long>, ? extends Publisher<?>>, Publisher<? extends T>) - Constructor for class reactor.rx.action.control.RepeatWhenAction
 
reply() - Method in class reactor.groovy.support.ClosureEventConsumer.ReplyDecorator
 
reply(Object) - Method in class reactor.groovy.support.ClosureEventConsumer.ReplyDecorator
 
reply(String) - Method in class reactor.io.net.impl.zmq.tcp.ZeroMQ
 
ReplyDecorator(Object, Bus) - Constructor for class reactor.groovy.support.ClosureEventConsumer.ReplyDecorator
 
request(long) - Method in class reactor.core.reactivestreams.SerializedSubscriber
 
request(long) - Method in class reactor.core.reactivestreams.SubscriberBarrier
 
request(long) - Method in class reactor.core.reactivestreams.SubscriptionWithContext
 
request(Method, String, ReactorChannelHandler<IN, OUT, HttpChannel<IN, OUT>>) - Method in class reactor.io.net.http.HttpClient
Use the passed HTTP method to send to the given URL.
request(Method, String, ReactorChannelHandler<IN, OUT, HttpChannel<IN, OUT>>) - Method in class reactor.io.net.impl.netty.http.NettyHttpClient
 
request - Variable in class reactor.io.net.impl.netty.http.NettyHttpClientHandler
 
request - Variable in class reactor.io.net.impl.netty.http.NettyHttpServerHandler
 
request(String) - Method in class reactor.io.net.impl.zmq.tcp.ZeroMQ
 
request(long) - Method in class reactor.rx.action.combination.FanInAction.InnerSubscriber
 
request(long) - Method in class reactor.rx.action.combination.FanInSubscription.InnerSubscription
 
request(long) - Method in class reactor.rx.action.combination.SwitchAction.SwitchSubscriber
 
request(long) - Method in class reactor.rx.action.combination.ZipAction.InnerSubscriber
 
request(long) - Method in class reactor.rx.subscription.BatchSubscription
 
request(long) - Method in class reactor.rx.subscription.DropSubscription
 
request(long) - Method in class reactor.rx.subscription.PushSubscription
 
request(long) - Method in class reactor.rx.subscription.ReactiveSubscription
 
request(long) - Method in class reactor.rx.subscription.support.WrappedSubscription
 
REQUEST_ENTITY_TOO_LARGE - Static variable in class reactor.io.net.http.model.Status
413 Request Entity Too Large
REQUEST_HEADER_FIELDS_TOO_LARGE - Static variable in class reactor.io.net.http.model.Status
431 Request Header Fields Too Large (RFC6585)
REQUEST_TIMEOUT - Static variable in class reactor.io.net.http.model.Status
408 Request Timeout
REQUEST_URI_TOO_LONG - Static variable in class reactor.io.net.http.model.Status
414 Request-URI Too Long
requestAll() - Method in class reactor.rx.action.Action
 
requestAll() - Method in interface reactor.rx.action.Control
Usually requests Long.MAX_VALUE, which instructs a stream to never end until completed or cancelled.
requestAll() - Method in class reactor.rx.action.support.TapAndControls
 
REQUESTED_RANGE_NOT_SATISFIABLE - Static variable in class reactor.io.net.http.model.Status
416 Requested Range Not Satisfiable
REQUESTED_UPDATER - Static variable in class reactor.rx.action.combination.DynamicMergeAction
 
requestMore(long) - Method in class reactor.rx.action.Action
 
requestMore(long) - Method in class reactor.rx.action.combination.DynamicMergeAction
 
requestMore(long) - Method in class reactor.rx.action.combination.FanInAction
 
requestMore(long) - Method in class reactor.rx.action.control.DispatcherAction
 
requestMore(long) - Method in class reactor.rx.action.control.RepeatAction
 
requestMore(long) - Method in class reactor.rx.action.control.RepeatWhenAction
 
requestMore(long) - Method in interface reactor.rx.action.Control
Request the next n elements from the source
requestMore(long) - Method in class reactor.rx.action.control.ThrottleRequestAction
 
requestMore(long) - Method in class reactor.rx.action.control.ThrottleRequestWhenAction
 
requestMore(long) - Method in class reactor.rx.action.error.RetryAction
 
requestMore(long) - Method in class reactor.rx.action.error.TimeoutAction
 
requestMore(long) - Method in class reactor.rx.action.filter.TakeAction
 
requestMore(long) - Method in class reactor.rx.action.passive.LoggerAction
 
requestMore(long) - Method in class reactor.rx.action.support.TapAndControls
 
requestMore(long) - Method in class reactor.rx.action.terminal.AdaptiveConsumerAction
 
requestMore(long) - Method in class reactor.rx.action.terminal.ConsumerAction
 
requestMore(long) - Method in class reactor.rx.action.transformation.GroupByAction
 
requestUpstream(long, boolean, long) - Method in class reactor.rx.action.Action
 
requestUpstream(long, boolean, long) - Method in class reactor.rx.action.combination.ConcatAction
 
requestUpstream(long, boolean, long) - Method in class reactor.rx.action.combination.DynamicMergeAction
 
requestUpstream(long, boolean, long) - Method in class reactor.rx.action.combination.FanInAction
 
requestUpstream(long, boolean, long) - Method in class reactor.rx.action.combination.SwitchAction
 
requestUpstream(long, boolean, long) - Method in class reactor.rx.action.combination.ZipAction
 
requestUpstream(long, boolean, long) - Method in class reactor.rx.action.control.DispatcherAction
 
requestUpstream(long, boolean, long) - Method in class reactor.rx.action.error.FallbackAction
 
requestUpstream(long, boolean, long) - Method in class reactor.rx.broadcast.Broadcaster
 
requestWhen(Function<? super Stream<? extends Long>, ? extends Publisher<? extends Long>>) - Method in class reactor.rx.Stream
Request the parent stream every time the passed throttleStream signals a Long request volume.
RESERVED_SLOTS - Static variable in class reactor.rx.action.Action
onComplete, onError, request, onSubscribe are dispatched events, therefore up to capacity + 4 events can be in-flight stacking into a Dispatcher.
reset() - Method in class reactor.fn.timer.HashWheelTimer.TimerPausable
Reset the Registration
reset() - Method in class reactor.io.buffer.Buffer
Reset the buffer to the previously-saved position and limit.
RESET_CONTENT - Static variable in class reactor.io.net.http.model.Status
205 Reset Content
resolve(Object) - Method in interface reactor.bus.selector.HeaderResolver
Resolve the headers that might be encoded in a key.
Resource - Interface in reactor.fn
A Resource is a component with an active state, generally consuming hardware capacities (memory, cpu, io).
respondsToKey(Object) - Method in interface reactor.bus.Bus
Are there any Registrations with Selectors that match the given key.
respondsToKey(Object) - Method in class reactor.bus.EventBus
 
responseHeader(String, String) - Method in class reactor.io.net.http.HttpChannel
Define the response HTTP header for the given key
responseHeaders() - Method in class reactor.io.net.http.HttpChannel
 
ResponseHeaders - Interface in reactor.io.net.http.model
 
responseHeaders() - Method in class reactor.io.net.impl.netty.http.NettyHttpChannel
 
responseStatus() - Method in class reactor.io.net.http.HttpChannel
 
responseStatus(Status) - Method in class reactor.io.net.http.HttpChannel
Set the response status to an outgoing response
responseStatus() - Method in class reactor.io.net.impl.netty.http.NettyHttpChannel
 
resume() - Method in class reactor.bus.registry.CachableRegistration
 
resume() - Method in interface reactor.bus.registry.Registration
Unpause this Registration, making it available for selection.
resume() - Method in interface reactor.fn.Pausable
Unpause this Pausable.
resume() - Method in class reactor.fn.timer.HashWheelTimer.TimerPausable
Resume current Registration
retain() - Method in class reactor.alloc.AbstractReference
 
retain(int) - Method in class reactor.alloc.AbstractReference
 
retain() - Method in interface reactor.alloc.Reference
Increase reference count by 1.
retain(int) - Method in interface reactor.alloc.Reference
Increase reference count by incr amount.
retainAll(Collection<?>) - Method in class reactor.core.queue.internal.MpscLinkedQueue
 
retry() - Method in class reactor.rx.Stream
Create a new Stream which will re-subscribe its oldest parent-child stream pair.
retry(int) - Method in class reactor.rx.Stream
Create a new Stream which will re-subscribe its oldest parent-child stream pair.
retry(Predicate<Throwable>) - Method in class reactor.rx.Stream
Create a new Stream which will re-subscribe its oldest parent-child stream pair.
retry(int, Predicate<Throwable>) - Method in class reactor.rx.Stream
Create a new Stream which will re-subscribe its oldest parent-child stream pair.
RETRY_AFTER - Static variable in interface reactor.io.net.http.model.ResponseHeaders
The HTTP Retry-After header field name.
RetryAction<T> - Class in reactor.rx.action.error
 
RetryAction(Dispatcher, int, Predicate<Throwable>, Publisher<? extends T>) - Constructor for class reactor.rx.action.error.RetryAction
 
retryStream() - Method in class reactor.rx.action.error.RetryWhenAction
 
retryWhen(Function<? super Stream<? extends Throwable>, ? extends Publisher<?>>) - Method in class reactor.rx.Stream
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.
RetryWhenAction<T> - Class in reactor.rx.action.error
 
RetryWhenAction(Dispatcher, Function<? super Stream<? extends Throwable>, ? extends Publisher<?>>, Publisher<? extends T>) - Constructor for class reactor.rx.action.error.RetryWhenAction
 
reuseAddr() - Method in class reactor.io.net.config.ServerSocketOptions
Returns a boolean indicating whether or not SO_REUSEADDR is enabled
reuseAddr(boolean) - Method in class reactor.io.net.config.ServerSocketOptions
Enables or disables SO_REUSEADDR.
rewind() - Method in class reactor.io.buffer.Buffer
Rewind this Buffer to the beginning.
rewind(int) - Method in class reactor.io.buffer.Buffer
Rewinds this buffer by len bytes.
RingBufferDispatcher - Class in reactor.core.dispatch
Implementation of a Dispatcher that uses a RingBuffer to queue tasks to execute.
RingBufferDispatcher(String) - Constructor for class reactor.core.dispatch.RingBufferDispatcher
Creates a new RingBufferDispatcher with the given name.
RingBufferDispatcher(String, int) - Constructor for class reactor.core.dispatch.RingBufferDispatcher
Creates a new RingBufferDispatcher with the given name and , configured with a producer type of MULTI and a blocking wait strategy.
RingBufferDispatcher(String, int, Consumer<Throwable>) - Constructor for class reactor.core.dispatch.RingBufferDispatcher
Creates a new RingBufferDispatcher with the given name.
RingBufferDispatcher(String, int, Consumer<Throwable>, ProducerType, WaitStrategy) - Constructor for class reactor.core.dispatch.RingBufferDispatcher
Creates a new RingBufferDispatcher with the given name.
RingBufferProcessor<E> - Class in reactor.core.processor
An implementation of a RingBuffer backed message-passing Processor.
RingBufferSubscriberUtils - Class in reactor.core.processor.util
Utility methods to perform common tasks associated with Subscriber handling when the signals are stored in a RingBuffer.
RingBufferWorkProcessor<E> - Class in reactor.core.processor
An implementation of a RingBuffer backed message-passing WorkProcessor.
roundRobin(T...) - Static method in class reactor.fn.Suppliers
Deprecated.
Create a Supplier that continually round-robin load balances each call to Supplier.get() by iterating over the objects.
roundRobinEventRouting() - Method in class reactor.bus.spec.EventRoutingComponentSpec
Configures the component's EventRouter to route events to one consumer selected from the matching consumers using a round-robin algorithm consumers
RoundRobinFilter - Class in reactor.bus.filter
A Filter implementation that returns a single item.
RoundRobinFilter() - Constructor for class reactor.bus.filter.RoundRobinFilter
 
route(Object, E, List<Registration<Object, ? extends Consumer<? extends Event<?>>>>, Consumer<E>, Consumer<Throwable>) - Method in class reactor.bus.routing.ConsumerFilteringRouter
 
route(Object, E, List<Registration<Object, ? extends Consumer<? extends Event<?>>>>, Consumer<E>, Consumer<Throwable>) - Method in interface reactor.bus.routing.Router
Routes the event, triggered by a notification with the given key to the consumers.
route(Object, E, List<Registration<Object, ? extends Consumer<? extends Event<?>>>>, Consumer<E>, Consumer<Throwable>) - Method in class reactor.bus.routing.TraceableDelegatingRouter
 
route(AbstractLifecycleDispatcher.Task) - Static method in class reactor.core.dispatch.AbstractLifecycleDispatcher
 
route(MutableSignal<E>, Subscriber<? super E>) - Static method in class reactor.core.processor.util.RingBufferSubscriberUtils
 
route(Object, E, List<Registration<Object, ? extends Consumer<? extends Event<?>>>>, Consumer<E>, Consumer<Throwable>) - Method in class reactor.groovy.config.StreamRouter
 
route(Selector<HttpChannel>, ReactorChannelHandler<IN, OUT, HttpChannel<IN, OUT>>) - Method in class reactor.io.net.http.HttpServer
Register an handler for the given Selector condition, incoming connections will query the internal registry to invoke the matching handlers.
routeChannel(HttpChannel<IN, OUT>) - Method in class reactor.io.net.http.HttpServer
 
routeChannel(HttpChannel<IN, OUT>) - Method in class reactor.io.net.impl.netty.http.NettyHttpServer
 
routedWriters - Variable in class reactor.io.net.http.HttpServer
 
routeError(Throwable) - Method in class reactor.Environment
Route any exception to the environment error journal this#errorConsumer.
routeOnce(MutableSignal<E>, Subscriber<? super E>) - Static method in class reactor.core.processor.util.RingBufferSubscriberUtils
 
Router - Interface in reactor.bus.routing
An Router is used to route an Object to Consumers.
router(String) - Method in class reactor.io.net.impl.zmq.tcp.ZeroMQ
 
routingStrategy(String) - Method in class reactor.groovy.config.ReactorBuilder
 
run() - Method in class reactor.core.dispatch.MultiThreadDispatcher.MultiThreadTask
 
run() - Method in class reactor.core.dispatch.SingleThreadDispatcher.SingleThreadTask
 
run() - Method in class reactor.fn.timer.HashWheelTimer.TimerPausable
Run the delegate of the current Registration
run() - Method in class reactor.groovy.config.ReactorScriptWrapper
 
run() - Method in class reactor.io.net.impl.zmq.ZeroMQWorker
 
RUNNING - Static variable in class reactor.rx.action.combination.FanInAction
 

S

sameOrNotEqual(V, V) - Method in class reactor.rx.stream.io.ChronicleStream
 
sample() - Method in class reactor.rx.Stream
Create a new Stream whose values will be only the last value of each batch.
sample(int) - Method in class reactor.rx.Stream
Create a new Stream whose values will be only the last value of each batch.
sample(long, TimeUnit) - Method in class reactor.rx.Stream
Create a new Stream whose values will be only the last value of each batch.
sample(long, TimeUnit, Timer) - Method in class reactor.rx.Stream
Create a new Stream whose values will be only the last value of each batch.
sample(int, long, TimeUnit) - Method in class reactor.rx.Stream
Create a new Stream whose values will be only the last value of each batch.
sample(int, long, TimeUnit, Timer) - Method in class reactor.rx.Stream
Create a new Stream whose values will be only the last value of each batch.
SampleAction<T> - Class in reactor.rx.action.aggregation
 
SampleAction(Dispatcher, int) - Constructor for class reactor.rx.action.aggregation.SampleAction
 
SampleAction(Dispatcher, boolean, int, long, TimeUnit, Timer) - Constructor for class reactor.rx.action.aggregation.SampleAction
 
SampleAction(Dispatcher, int, boolean) - Constructor for class reactor.rx.action.aggregation.SampleAction
 
sampleFirst() - Method in class reactor.rx.Stream
Create a new Stream whose values will be only the first value of each batch.
sampleFirst(int) - Method in class reactor.rx.Stream
Create a new Stream whose values will be only the first value of each batch.
sampleFirst(long, TimeUnit) - Method in class reactor.rx.Stream
Create a new Stream whose values will be only the first value of each batch.
sampleFirst(long, TimeUnit, Timer) - Method in class reactor.rx.Stream
Create a new Stream whose values will be only the first value of each batch.
sampleFirst(int, long, TimeUnit) - Method in class reactor.rx.Stream
Create a new Stream whose values will be only the first value of each batch.
sampleFirst(int, long, TimeUnit, Timer) - Method in class reactor.rx.Stream
Create a new Stream whose values will be only the first value of each batch.
scan(BiFunction<O, O, O>) - Method in class reactor.rx.Stream
Scan the values passing through this Stream into an object A.
scan(A, BiFunction<A, ? super O, A>) - Method in class reactor.rx.Stream
Scan the values passing through this Stream into an object A.
ScanAction<T,A> - Class in reactor.rx.action.transformation
 
ScanAction(A, BiFunction<A, ? super T, A>) - Constructor for class reactor.rx.action.transformation.ScanAction
 
scanByKey(Publisher<? extends Tuple2<K, V>>, BiFunction<V, V, V>) - Static method in class reactor.groovy.ext.StreamExtensions
 
scanByKey(Publisher<Tuple2<KEY, VALUE>>, BiFunction<VALUE, VALUE, VALUE>) - Static method in class reactor.rx.BiStreams
 
scanByKey(Publisher<Tuple2<KEY, VALUE>>, MapStream<KEY, VALUE>, BiFunction<VALUE, VALUE, VALUE>) - Static method in class reactor.rx.BiStreams
 
scanByKey(Publisher<Tuple2<KEY, VALUE>>, Map<KEY, VALUE>, Publisher<? extends MapStream.Signal<KEY, VALUE>>, BiFunction<VALUE, VALUE, VALUE>) - Static method in class reactor.rx.BiStreams
 
ScanByKeyAction<K,V> - Class in reactor.rx.action.pair
 
ScanByKeyAction(BiFunction<? super V, ? super V, V>, MapStream<K, V>) - Constructor for class reactor.rx.action.pair.ScanByKeyAction
 
ScanByKeyAction(BiFunction<? super V, ? super V, V>, Map<K, V>, Publisher<? extends MapStream.Signal<K, V>>) - Constructor for class reactor.rx.action.pair.ScanByKeyAction
 
scanByKeyOn(Publisher<Tuple2<KEY, VALUE>>, Map<KEY, VALUE>, Publisher<? extends MapStream.Signal<KEY, VALUE>>, BiFunction<VALUE, VALUE, VALUE>) - Static method in class reactor.rx.BiStreams
 
schedule(Consumer<T>, T) - Method in class reactor.bus.EventBus
Schedule an arbitrary Consumer to be executed on the current Reactor Dispatcher, passing the given .
schedule(Consumer<Long>, long, TimeUnit, long) - Method in class reactor.bus.timer.EventTimer
 
schedule(Consumer<Long>, long, TimeUnit) - Method in class reactor.bus.timer.EventTimer
 
schedule(Consumer<Long>, long, TimeUnit, long) - Method in class reactor.fn.timer.HashWheelTimer
 
schedule(Consumer<Long>, long, TimeUnit) - Method in class reactor.fn.timer.HashWheelTimer
 
schedule(Consumer<Long>, long, TimeUnit, long) - Method in interface reactor.fn.timer.Timer
Schedule a recurring task.
schedule(Consumer<Long>, long, TimeUnit) - Method in interface reactor.fn.timer.Timer
Schedule a recurring task.
schedule(EventBus, T, Closure) - Static method in class reactor.groovy.ext.ReactorStaticExtensions
 
scheduleCompletion() - Method in class reactor.rx.action.combination.FanInAction
 
scheduleLater(AbstractLifecycleDispatcher.Task) - Method in class reactor.core.dispatch.AbstractLifecycleDispatcher
 
scheduleLater(AbstractLifecycleDispatcher.Task) - Method in class reactor.core.dispatch.MultiThreadDispatcher
 
SEE_OTHER - Static variable in class reactor.io.net.http.model.Status
303 See Other (since HTTP/1.1)
select(K) - Method in class reactor.bus.registry.CachingRegistry
 
select(K) - Method in interface reactor.bus.registry.Registry
Select Registrations whose Selector Selector.matches(Object) the given key.
select(K) - Method in class reactor.bus.registry.SimpleCachingRegistry
 
Selector<T> - Interface in reactor.bus.selector
A Selector is a wrapper around an arbitrary object.
SelectorProcessor(Processor<Event<?>, Event<?>>, Selector) - Constructor for class reactor.groovy.config.ReactorBuilder.SelectorProcessor
 
Selectors - Class in reactor.bus.selector
Helper methods for creating Selectors.
Selectors() - Constructor for class reactor.bus.selector.Selectors
 
Selectors.AnonymousKey - Class in reactor.bus.selector
 
send(Object, Event<?>) - Method in class reactor.bus.EventBus
Notify this component of the given Event and register an internal Consumer that will take the output of a previously-registered Function and respond using the key set on the Event's replyTo property.
send(Object, Supplier<? extends Event<?>>) - Method in class reactor.bus.EventBus
Notify this component that the given Supplier will provide an Event and register an internal Consumer that will take the output of a previously-registered Function and respond using the key set on the Event's replyTo property.
send(Object, Event<?>, Bus) - Method in class reactor.bus.EventBus
Notify this component of the given Event and register an internal Consumer that will take the output of a previously-registered Function and respond to the key set on the Event's replyTo property and will call the notify method on the given Bus.
send(Object, Supplier<? extends Event<?>>, Bus) - Method in class reactor.bus.EventBus
Notify this component that the given Supplier will provide an Event and register an internal Consumer that will take the output of a previously-registered Function and respond to the key set on the Event's replyTo property and will call the notify method on the given Bus.
send(EventBus, Object, T) - Static method in class reactor.groovy.ext.BusExtensions
 
send(EventBus, Object, T, Closure) - Static method in class reactor.groovy.ext.BusExtensions
 
send(EventBus, Object, Event<T>, Closure) - Static method in class reactor.groovy.ext.BusExtensions
 
sendAndReceive(Object, Event<?>, Consumer<T>) - Method in class reactor.bus.EventBus
Register the given Consumer on an anonymous Selector and set the given event's replyTo property to the corresponding anonymous key, then register the consumer to receive replies from the Function assigned to handle the given key.
sendAndReceive(Object, Supplier<? extends Event<?>>, Consumer<T>) - Method in class reactor.bus.EventBus
Register the given Consumer on an anonymous Selector and set the event's replyTo property to the corresponding anonymous key, then register the consumer to receive replies from the Function assigned to handle the given key.
serialComplete() - Method in class reactor.rx.action.combination.FanInSubscription
 
serialError(Throwable) - Method in class reactor.rx.action.combination.FanInSubscription
 
SerializationCodec<E,IN,OUT> - Class in reactor.io.codec
Abstract base class for Codec Codecs that perform serialization of objects.
SerializationCodec(E, boolean) - Constructor for class reactor.io.codec.SerializationCodec
Create a SerializationCodec using the given engine and specifying whether or not to prepend a length field to frame the message.
SerializedBroadcaster<O> - Class in reactor.rx.broadcast
A Broadcaster is a subclass of Stream which exposes methods for publishing values into the pipeline.
SerializedSubscriber<T> - Class in reactor.core.reactivestreams
serializer(ObjectMapper) - Method in class reactor.io.codec.json.JacksonJsonCodec
 
serializer(Kryo) - Method in class reactor.io.codec.kryo.KryoCodec
 
serializer(KryoPool) - Method in class reactor.io.codec.kryo.KryoPoolCodec
 
serializer(Map<Class<?>, Message>) - Method in class reactor.io.codec.protobuf.ProtobufCodec
 
serializer(E) - Method in class reactor.io.codec.SerializationCodec
 
serializer - Variable in class reactor.rx.action.combination.FanInSubscription
 
serialNext(E) - Method in class reactor.rx.action.combination.FanInSubscription
 
SERVER - Static variable in interface reactor.io.net.http.model.ResponseHeaders
The HTTP Server header field name.
server - Variable in class reactor.io.net.impl.netty.http.NettyHttpServer
 
serverImplCtor - Variable in class reactor.io.net.Spec.DatagramServerSpec
 
ServerSocketOptions - Class in reactor.io.net.config
Encapsulates configuration options for server sockets.
ServerSocketOptions() - Constructor for class reactor.io.net.config.ServerSocketOptions
 
SERVICE_UNAVAILABLE - Static variable in class reactor.io.net.http.model.Status
503 Service Unavailable
set(String, V) - Method in class reactor.bus.Event.Headers
Set the header value.
set(String, String) - Method in interface reactor.io.net.http.model.WritableHeaders
 
set(String, Iterable<String>) - Method in interface reactor.io.net.http.model.WritableHeaders
 
set(String, String) - Method in class reactor.io.net.impl.netty.http.NettyHttpHeaders
 
set(String, Iterable<String>) - Method in class reactor.io.net.impl.netty.http.NettyHttpHeaders
 
set(String, String) - Method in class reactor.io.net.impl.netty.http.NettyHttpResponseHeaders
 
set(String, Iterable<String>) - Method in class reactor.io.net.impl.netty.http.NettyHttpResponseHeaders
 
SET_COOKIE - Static variable in interface reactor.io.net.http.model.ResponseHeaders
The HTTP Set-Cookie header field name.
SET_COOKIE2 - Static variable in interface reactor.io.net.http.model.ResponseHeaders
The HTTP Set-Cookie2 header field name.
setAll(Map<String, Object>) - Method in class reactor.bus.Event.Headers
Sets all of the headers represented by entries in the given headers Map.
setBacklog(Integer) - Method in class reactor.groovy.config.DispatcherConfigurationBuilder
 
setBacklog(int) - Method in class reactor.logback.AsyncAppender
 
setBasePath(String) - Method in class reactor.logback.DurableAsyncAppender
 
setConnectionId(String) - Method in class reactor.io.net.impl.zmq.ZeroMQChannelStream
 
setData(T) - Method in class reactor.bus.Event
Set the internal data to wrap.
setData(Object) - Method in class reactor.core.dispatch.AbstractLifecycleDispatcher.Task
 
setDefaultDispatcher(String) - Method in class reactor.groovy.config.EnvironmentBuilder
 
setDispatcher(String, Dispatcher) - Method in class reactor.Environment
Adds the dispatcher to the environment, storing it using the given name.
setDispatcher(Dispatcher) - Method in class reactor.groovy.config.ReactorBuilder
 
setEnv(Environment) - Method in class reactor.groovy.config.ReactorBuilder
 
setErrorConsumer(Consumer<Throwable>) - Method in class reactor.core.dispatch.AbstractLifecycleDispatcher.Task
 
setEventConsumer(Consumer<?>) - Method in class reactor.core.dispatch.AbstractLifecycleDispatcher.Task
 
setFilter(Filter) - Method in class reactor.groovy.config.ReactorBuilder
 
setIncludeCallerData(boolean) - Method in class reactor.logback.AsyncAppender
 
setKey(Object) - Method in class reactor.bus.Event
Set the key this event is being notified with.
setMembership(Set) - Static method in class reactor.bus.selector.Selectors
Creates a Selector that matches objects on set membership.
SetMembershipSelector - Class in reactor.bus.selector
Implementation of Selector that matches objects on set membership.
SetMembershipSelector(Set) - Constructor for class reactor.bus.selector.SetMembershipSelector
Create a Selector when the given regex pattern.
setMetaClass(MetaClass) - Method in class reactor.groovy.config.DispatcherConfigurationBuilder
 
setMetaClass(MetaClass) - Method in class reactor.groovy.config.DSLUtils
 
setMetaClass(MetaClass) - Method in class reactor.groovy.config.EnvironmentBuilder
 
setMetaClass(MetaClass) - Method in class reactor.groovy.config.GroovyEnvironment
 
setMetaClass(MetaClass) - Method in class reactor.groovy.config.ReactorBuilder.NestedReactorBuilder
 
setMetaClass(MetaClass) - Method in class reactor.groovy.config.ReactorBuilder.SelectorProcessor
 
setMetaClass(MetaClass) - Method in class reactor.groovy.config.ReactorBuilder
 
setMetaClass(MetaClass) - Method in class reactor.groovy.ext.BusExtensions
 
setMetaClass(MetaClass) - Method in class reactor.groovy.ext.ReactorStaticExtensions
 
setMetaClass(MetaClass) - Method in class reactor.groovy.ext.StreamExtensions
 
setMetaClass(MetaClass) - Method in class reactor.groovy.support.ClosureConsumer
 
setMetaClass(MetaClass) - Method in class reactor.groovy.support.ClosureEventConsumer.ReplyDecorator
 
setMetaClass(MetaClass) - Method in class reactor.groovy.support.ClosureEventConsumer
 
setMetaClass(MetaClass) - Method in class reactor.groovy.support.ClosureEventFunction
 
setMetaClass(MetaClass) - Method in class reactor.groovy.support.ClosureFunction
 
setMetaClass(MetaClass) - Method in class reactor.groovy.support.ClosurePredicate
 
setMetaClass(MetaClass) - Method in class reactor.groovy.support.ClosureReduce
 
setMetaClass(MetaClass) - Method in class reactor.groovy.support.ClosureSupplier
 
setName(String) - Method in class reactor.logback.AsyncAppender
 
setOrigin(UUID) - Method in class reactor.bus.Event.Headers
Set the origin header.
setOrigin(String) - Method in class reactor.bus.Event.Headers
Set the origin header.
setOverride(boolean) - Method in class reactor.groovy.config.ReactorBuilder
 
setProperty(String, Object) - Method in class reactor.groovy.config.DispatcherConfigurationBuilder
 
setProperty(String, Object) - Method in class reactor.groovy.config.DSLUtils
 
setProperty(String, Object) - Method in class reactor.groovy.config.EnvironmentBuilder
 
setProperty(String, Object) - Method in class reactor.groovy.config.GroovyEnvironment
 
setProperty(String, Object) - Method in class reactor.groovy.config.ReactorBuilder.NestedReactorBuilder
 
setProperty(String, Object) - Method in class reactor.groovy.config.ReactorBuilder.SelectorProcessor
 
setProperty(String, Object) - Method in class reactor.groovy.config.ReactorBuilder
 
setProperty(String, Object) - Method in class reactor.groovy.ext.BusExtensions
 
setProperty(String, Object) - Method in class reactor.groovy.ext.ReactorStaticExtensions
 
setProperty(String, Object) - Method in class reactor.groovy.ext.StreamExtensions
 
setProperty(String, Object) - Method in class reactor.groovy.support.ClosureConsumer
 
setProperty(String, Object) - Method in class reactor.groovy.support.ClosureEventConsumer.ReplyDecorator
 
setProperty(String, Object) - Method in class reactor.groovy.support.ClosureEventConsumer
 
setProperty(String, Object) - Method in class reactor.groovy.support.ClosureEventFunction
 
setProperty(String, Object) - Method in class reactor.groovy.support.ClosureFunction
 
setProperty(String, Object) - Method in class reactor.groovy.support.ClosurePredicate
 
setProperty(String, Object) - Method in class reactor.groovy.support.ClosureReduce
 
setProperty(String, Object) - Method in class reactor.groovy.support.ClosureSupplier
 
setReactorEnvironment(Environment) - Method in class reactor.groovy.config.GroovyEnvironment
 
setReplyTo(Object) - Method in class reactor.bus.Event
Set the key that interested parties should send replies to.
setRouter(Router) - Method in class reactor.groovy.config.ReactorBuilder
 
setSize(Integer) - Method in class reactor.groovy.config.DispatcherConfigurationBuilder
 
setSocket(ZMQ.Socket) - Method in class reactor.io.net.impl.zmq.ZeroMQChannelStream
 
setTimer(Timer) - Static method in class reactor.fn.timer.TimeUtils
 
setType(DispatcherType) - Method in class reactor.groovy.config.DispatcherConfigurationBuilder
 
setValue(int) - Method in class reactor.alloc.RecyclableNumber
 
setValue(long) - Method in class reactor.alloc.RecyclableNumber
 
setValue(float) - Method in class reactor.alloc.RecyclableNumber
 
setValue(double) - Method in class reactor.alloc.RecyclableNumber
 
setValue(String) - Method in class reactor.alloc.RecyclableString
 
share() - Static method in class reactor.core.processor.RingBufferProcessor
Create a new RingBufferProcessor using ReactorProcessor.SMALL_BUFFER_SIZE backlog size, blockingWait Strategy and auto-cancel.
share(boolean) - Static method in class reactor.core.processor.RingBufferProcessor
Create a new RingBufferProcessor using ReactorProcessor.SMALL_BUFFER_SIZE backlog size, blockingWait Strategy and the passed auto-cancel setting.
share(ExecutorService) - Static method in class reactor.core.processor.RingBufferProcessor
Create a new RingBufferProcessor using ReactorProcessor.SMALL_BUFFER_SIZE backlog size, blockingWait Strategy and auto-cancel.
share(ExecutorService, boolean) - Static method in class reactor.core.processor.RingBufferProcessor
Create a new RingBufferProcessor using ReactorProcessor.SMALL_BUFFER_SIZE backlog size, blockingWait Strategy and the passed auto-cancel setting.
share(String, int) - Static method in class reactor.core.processor.RingBufferProcessor
Create a new RingBufferProcessor using ReactorProcessor.SMALL_BUFFER_SIZE backlog size, blockingWait Strategy and the passed auto-cancel setting.
share(String, int, boolean) - Static method in class reactor.core.processor.RingBufferProcessor
Create a new RingBufferProcessor using the blockingWait Strategy, passed backlog size, and auto-cancel settings.
share(ExecutorService, int) - Static method in class reactor.core.processor.RingBufferProcessor
Create a new RingBufferProcessor using passed backlog size, blockingWait Strategy and will auto-cancel.
share(ExecutorService, int, boolean) - Static method in class reactor.core.processor.RingBufferProcessor
Create a new RingBufferProcessor using passed backlog size, blockingWait Strategy and the auto-cancel argument.
share(String, int, WaitStrategy) - Static method in class reactor.core.processor.RingBufferProcessor
Create a new RingBufferProcessor using passed backlog size, wait strategy and will auto-cancel.
share(String, int, WaitStrategy, boolean) - Static method in class reactor.core.processor.RingBufferProcessor
Create a new RingBufferProcessor using passed backlog size, wait strategy and auto-cancel settings.
share(ExecutorService, int, WaitStrategy) - Static method in class reactor.core.processor.RingBufferProcessor
Create a new RingBufferProcessor using passed backlog size, wait strategy and will auto-cancel.
share(ExecutorService, int, WaitStrategy, boolean) - Static method in class reactor.core.processor.RingBufferProcessor
Create a new RingBufferProcessor using passed backlog size, wait strategy and auto-cancel settings.
share() - Static method in class reactor.core.processor.RingBufferWorkProcessor
Create a new RingBufferWorkProcessor using ReactorProcessor.SMALL_BUFFER_SIZE backlog size, blockingWait Strategy and auto-cancel.
share(boolean) - Static method in class reactor.core.processor.RingBufferWorkProcessor
Create a new RingBufferWorkProcessor using ReactorProcessor.SMALL_BUFFER_SIZE backlog size, blockingWait Strategy and the passed auto-cancel setting.
share(ExecutorService) - Static method in class reactor.core.processor.RingBufferWorkProcessor
Create a new RingBufferWorkProcessor using ReactorProcessor.SMALL_BUFFER_SIZE backlog size, blockingWait Strategy and auto-cancel.
share(ExecutorService, boolean) - Static method in class reactor.core.processor.RingBufferWorkProcessor
Create a new RingBufferWorkProcessor using ReactorProcessor.SMALL_BUFFER_SIZE backlog size, blockingWait Strategy and the passed auto-cancel setting.
share(String, int) - Static method in class reactor.core.processor.RingBufferWorkProcessor
Create a new RingBufferProcessor using the passed buffer size, blockingWait Strategy and auto-cancel.
share(String, int, boolean) - Static method in class reactor.core.processor.RingBufferWorkProcessor
Create a new RingBufferProcessor using the passed buffer size, blockingWait Strategy and the passed auto-cancel setting.
share(ExecutorService, int) - Static method in class reactor.core.processor.RingBufferWorkProcessor
Create a new RingBufferProcessor using the passed buffer size, blockingWait Strategy and auto-cancel.
share(ExecutorService, int, boolean) - Static method in class reactor.core.processor.RingBufferWorkProcessor
Create a new RingBufferWorkProcessor using the passed buffer size, blockingWait Strategy and auto-cancel.
share(String, int, WaitStrategy) - Static method in class reactor.core.processor.RingBufferWorkProcessor
Create a new RingBufferWorkProcessor using the passed buffer size, blockingWait Strategy and auto-cancel.
share(String, int, WaitStrategy, boolean) - Static method in class reactor.core.processor.RingBufferWorkProcessor
Create a new RingBufferWorkProcessor using the passed buffer size, blockingWait Strategy and auto-cancel settings.
share(ExecutorService, int, WaitStrategy) - Static method in class reactor.core.processor.RingBufferWorkProcessor
Create a new RingBufferWorkProcessor using the passed buffer size and blockingWait Strategy settings but will auto-cancel.
share(ExecutorService, int, WaitStrategy, boolean) - Static method in class reactor.core.processor.RingBufferWorkProcessor
Create a new RingBufferWorkProcessor using the passed buffer size, wait strategy and auto-cancel settings.
SHARED - Static variable in class reactor.Environment
The name of the default shared dispatcher
sharedDispatcher() - Static method in class reactor.Environment
Obtain the default dispatcher from the current environment.
shift(int) - Method in class reactor.rx.action.combination.FanInSubscription
 
shouldRequestPendingSignals() - Method in class reactor.rx.subscription.PushSubscription
 
shouldRequestPendingSignals() - Method in class reactor.rx.subscription.ReactiveSubscription
 
shouldRequestPendingSignals() - Method in class reactor.rx.subscription.support.WrappedSubscription
 
shutdown() - Method in class reactor.core.dispatch.AbstractLifecycleDispatcher
 
shutdown() - Method in class reactor.core.dispatch.MpscDispatcher
 
shutdown() - Method in class reactor.core.dispatch.RingBufferDispatcher
 
shutdown() - Method in class reactor.core.dispatch.SynchronousDispatcher
 
shutdown() - Method in class reactor.core.dispatch.TailRecurseDispatcher
 
shutdown() - Method in class reactor.core.dispatch.ThreadPoolExecutorDispatcher
 
shutdown() - Method in class reactor.core.dispatch.TraceableDelegatingDispatcher
 
shutdown() - Method in class reactor.core.dispatch.WorkQueueDispatcher
 
shutdown() - Method in class reactor.core.processor.ExecutorPoweredProcessor
 
shutdown() - Method in class reactor.core.processor.util.SingleUseExecutor
 
shutdown() - Method in class reactor.Environment
Shuts down this Environment, causing all of its Dispatchers to be shut down.
shutdown() - Method in interface reactor.fn.Resource
Shutdown this active Resource such that it can no longer be used.
shutdown() - Method in class reactor.io.net.impl.zmq.tcp.ZeroMQ
 
shutdown() - Method in class reactor.io.net.impl.zmq.ZeroMQWorker
 
shutdown() - Method in class reactor.io.net.ReactorPeer
Shutdown this Peer and complete the returned Promise when shut down.
shutdownNow() - Method in class reactor.core.processor.util.SingleUseExecutor
 
Signal<T> - Class in reactor.rx.action
A domain representation of a Reactive Stream signal.
Signal.Type - Enum in reactor.rx.action
 
signalAllWhenBlocking() - Method in class reactor.core.dispatch.wait.AgileWaitingStrategy
 
signalAllWhenBlocking() - Method in class reactor.core.dispatch.wait.ParkWaitStrategy
 
SimpleCachingRegistry<K,V> - Class in reactor.bus.registry
A naive caching Registry implementation for use in situations that the default CachingRegistry can't be used due to its reliance on the gs-collections library.
simplePredicate - Static variable in class reactor.rx.action.filter.FilterAction
 
SingleThreadDispatcher - Class in reactor.core.dispatch
Base Implementation for single-threaded Dispatchers.
SingleThreadDispatcher(int) - Constructor for class reactor.core.dispatch.SingleThreadDispatcher
 
SingleThreadDispatcher.SingleThreadTask - Class in reactor.core.dispatch
 
SingleThreadTask() - Constructor for class reactor.core.dispatch.SingleThreadDispatcher.SingleThreadTask
 
SingleTimerStream - Class in reactor.rx.stream
A Stream that emits 0 after an initial delay and then complete The SingleTimerStream will manage dedicated timers for new subscriber assigned via this#subscribe(org.reactivestreams.Subscriber).
SingleTimerStream(long, TimeUnit, Timer) - Constructor for class reactor.rx.stream.SingleTimerStream
 
SingleUseExecutor - Class in reactor.core.processor.util
 
SingleValueStream<T> - Class in reactor.rx.stream
A Stream that emits only one value and then complete.
SingleValueStream(T) - Constructor for class reactor.rx.stream.SingleValueStream
 
size() - Method in class reactor.core.queue.internal.MpscLinkedQueue
 
size - Variable in class reactor.fn.tuple.Tuple
 
size() - Method in class reactor.fn.tuple.Tuple
Return the number of elements in this Tuple.
size() - Method in class reactor.io.queue.ChronicleQueuePersistor
 
size() - Method in class reactor.io.queue.InMemoryQueuePersistor
 
size() - Method in class reactor.io.queue.PersistentQueue
 
size() - Method in interface reactor.io.queue.QueuePersistor
Get the number of items persisted right now.
size() - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
size() - Method in class reactor.rx.stream.io.ChronicleStream
 
skip(int) - Method in class reactor.io.buffer.Buffer
Skips len bytes.
skip(long) - Method in class reactor.rx.Stream
Create a new Stream that will NOT signal next elements up to times.
skip(long, TimeUnit) - Method in class reactor.rx.Stream
Create a new Stream that will NOT signal next elements up to the specified .
skip(long, TimeUnit, Timer) - Method in class reactor.rx.Stream
Create a new Stream that will NOT signal next elements up to the specified .
SkipAction<T> - Class in reactor.rx.action.filter
 
SkipAction(Predicate<T>, long) - Constructor for class reactor.rx.action.filter.SkipAction
 
SkipUntilTimeout<T> - Class in reactor.rx.action.filter
 
SkipUntilTimeout(long, TimeUnit, Timer) - Constructor for class reactor.rx.action.filter.SkipUntilTimeout
 
skipWhile(Predicate<O>) - Method in class reactor.rx.Stream
Create a new Stream that will NOT signal next elements while is true.
skipWhile(long, Predicate<O>) - Method in class reactor.rx.Stream
Create a new Stream that will NOT signal next elements while is true or up to times.
SleepWait() - Constructor for class reactor.fn.timer.HashWheelTimer.SleepWait
 
slice(int, int) - Method in class reactor.io.buffer.Buffer
Create a copy of the given range.
slice(int...) - Method in class reactor.io.buffer.Buffer
Slice this buffer at the given positions.
SMALL_BUFFER_SIZE - Static variable in class reactor.core.processor.ReactorProcessor
 
SMALL_BUFFER_SIZE - Static variable in class reactor.io.buffer.Buffer
The size, in bytes, of a small buffer.
SnappyCodec<IN,OUT> - Class in reactor.io.codec.compress
 
SnappyCodec(Codec<Buffer, IN, OUT>) - Constructor for class reactor.io.codec.compress.SnappyCodec
 
snapshot() - Method in class reactor.io.buffer.Buffer
Save the current buffer position and limit.
sndbuf() - Method in class reactor.io.net.config.CommonSocketOptions
Gets the configured SO_SNDBUF (send buffer) size
sndbuf(int) - Method in class reactor.io.net.config.CommonSocketOptions
Sets the SO_SNDBUF (send buffer) size
socketConfigurer() - Method in class reactor.io.net.impl.zmq.ZeroMQClientSocketOptions
The Consumer responsible for configuring the underlying ZeroMQ socket.
socketConfigurer(Consumer<ZMQ.Socket>) - Method in class reactor.io.net.impl.zmq.ZeroMQClientSocketOptions
Set the Consumer responsible for configure the underlying ZeroMQ socket.
socketConfigurer() - Method in class reactor.io.net.impl.zmq.ZeroMQServerSocketOptions
The Consumer responsible for configuring the underlying ZeroMQ socket.
socketConfigurer(Consumer<ZMQ.Socket>) - Method in class reactor.io.net.impl.zmq.ZeroMQServerSocketOptions
Set the Consumer responsible for configure the underlying ZeroMQ socket.
socketType() - Method in class reactor.io.net.impl.zmq.ZeroMQClientSocketOptions
The type of the ZMQ socket to create.
socketType(int) - Method in class reactor.io.net.impl.zmq.ZeroMQClientSocketOptions
Set the type of ZMQ socket to create.
socketType() - Method in class reactor.io.net.impl.zmq.ZeroMQServerSocketOptions
The type of the ZMQ socket to create.
socketType(int) - Method in class reactor.io.net.impl.zmq.ZeroMQServerSocketOptions
Set the type of ZMQ socket to create.
SocketUtils - Class in reactor.io.net.tcp.support
NOTE: This code is a copy of that available in the Spring Framework.
SocketUtils() - Constructor for class reactor.io.net.tcp.support.SocketUtils
Although SocketUtils consists solely of static utility methods, this constructor is intentionally public.
sort() - Method in class reactor.rx.Stream
Stage incoming values into a PriorityQueue<O> that will be re-ordered and signaled to the returned fresh Stream.
sort(int) - Method in class reactor.rx.Stream
Stage incoming values into a PriorityQueue<O> that will be re-ordered and signaled to the returned fresh Stream.
sort(Comparator<? super O>) - Method in class reactor.rx.Stream
Stage incoming values into a PriorityQueue<O> that will be re-ordered and signaled to the returned fresh Stream.
sort(int, Comparator<? super O>) - Method in class reactor.rx.Stream
Stage incoming values into a PriorityQueue<O> that will be re-ordered and signaled to the returned fresh Stream.
SortAction<T> - Class in reactor.rx.action.aggregation
 
SortAction(Dispatcher, int, Comparator<? super T>) - Constructor for class reactor.rx.action.aggregation.SortAction
 
Spec - Interface in reactor.io.net
Specifications used to build client and servers.
Spec.DatagramServerSpec<IN,OUT> - Class in reactor.io.net
 
Spec.HttpClientSpec<IN,OUT> - Class in reactor.io.net
A helper class for specifying a HttpClient
Spec.HttpServerSpec<IN,OUT> - Class in reactor.io.net
A HttpServer Spec is used to specify an HttpServer
Spec.IncrementalBackoffReconnect - Class in reactor.io.net
A helper class for configure a new Reconnect.
Spec.PeerSpec<IN,OUT,CONN extends ChannelStream<IN,OUT>,S extends Spec.PeerSpec<IN,OUT,CONN,S,N>,N extends ReactorPeer<IN,OUT,CONN>> - Class in reactor.io.net
 
Spec.TcpClientSpec<IN,OUT> - Class in reactor.io.net
A helper class for specifying a TcpClient
Spec.TcpServerSpec<IN,OUT> - Class in reactor.io.net
A TcpServerSpec is used to specify a TcpServer
spec_2_12_exception() - Static method in class reactor.core.support.SpecificationExceptions
 
spec_2_13_exception() - Static method in class reactor.core.support.SpecificationExceptions
 
spec_3_09_exception(long) - Static method in class reactor.core.support.SpecificationExceptions
 
SpecificationExceptions - Class in reactor.core.support
 
SpecificationExceptions() - Constructor for class reactor.core.support.SpecificationExceptions
 
split(int) - Method in class reactor.io.buffer.Buffer
Split this buffer on the given delimiter.
split(List<Buffer.View>, int) - Method in class reactor.io.buffer.Buffer
Split this buffer on the given delimiter but save memory by reusing the given List.
split(int, boolean) - Method in class reactor.io.buffer.Buffer
Split this buffer on the given delimiter and optionally leave the delimiter intact rather than stripping it.
split(List<Buffer.View>, int, boolean) - Method in class reactor.io.buffer.Buffer
Split this buffer on the given delimiter, save memory by reusing the given List, and optionally leave the delimiter intact rather than stripping it.
split(Buffer) - Method in class reactor.io.buffer.Buffer
Split this buffer on the given delimiter and leave the delimiter on the end of each segment.
split(Buffer, boolean) - Method in class reactor.io.buffer.Buffer
Split this buffer on the given delimiter.
split(List<Buffer.View>, Buffer, boolean) - Method in class reactor.io.buffer.Buffer
Split this buffer on the given delimiter.
split() - Method in class reactor.rx.Stream
Create a new Stream whose values will be each element E of any Iterable flowing this Stream When a new batch is triggered, the last value of that next batch will be pushed into this Stream.
split(long) - Method in class reactor.rx.Stream
Create a new Stream whose values will be each element E of any Iterable flowing this Stream When a new batch is triggered, the last value of that next batch will be pushed into this Stream.
SplitAction<T> - Class in reactor.rx.action.transformation
 
SplitAction() - Constructor for class reactor.rx.action.transformation.SplitAction
 
sse() - Method in class reactor.io.net.http.HttpChannel
 
ssl(SslOptions) - Method in class reactor.io.net.Spec.HttpClientSpec
Set the options to use for configuring SSL.
ssl(SslOptions) - Method in class reactor.io.net.Spec.HttpServerSpec
Set the options to use for configuring SSL.
ssl(SslOptions) - Method in class reactor.io.net.Spec.TcpClientSpec
Set the options to use for configuring SSL.
ssl(SslOptions) - Method in class reactor.io.net.Spec.TcpServerSpec
Set the options to use for configuring SSL.
SSLEngineSupplier - Class in reactor.io.net.tcp.ssl
 
SSLEngineSupplier(SslOptions, boolean) - Constructor for class reactor.io.net.tcp.ssl.SSLEngineSupplier
 
SslOptions - Class in reactor.io.net.config
Helper class encapsulating common SSL configuration options.
SslOptions() - Constructor for class reactor.io.net.config.SslOptions
 
sslProtocol() - Method in class reactor.io.net.config.SslOptions
 
sslProtocol(String) - Method in class reactor.io.net.config.SslOptions
 
StandardCodecs - Class in reactor.io.codec
A selection of standard codecs.
start() - Method in class reactor.fn.timer.HashWheelTimer
Start the Timer
start() - Method in class reactor.io.net.http.HttpServer
Start the server without any global handler, only the specific routed methods (get, post...) will apply.
start(ZMQ.Socket) - Method in class reactor.io.net.impl.zmq.ZeroMQWorker
 
start(ReactorChannelHandler<IN, OUT, CONN>, Reconnect) - Method in class reactor.io.net.ReactorClient
Open a channel to the configured address and return a Stream that will be populated by the ChannelStream every time a connection or reconnection is made.
start(ReactorChannelHandler<IN, OUT, CONN>) - Method in class reactor.io.net.ReactorPeer
Start this Peer.
start() - Method in class reactor.logback.AsyncAppender
 
start() - Method in class reactor.rx.subscription.FanOutSubscription
 
start() - Method in class reactor.rx.subscription.PushSubscription
 
started - Variable in class reactor.io.net.ReactorPeer
 
startWith(Iterable<O>) - Method in class reactor.rx.Stream
Start emitting all items from the passed publisher then emits from the current stream.
startWith(O) - Method in class reactor.rx.Stream
Start emitting all items from the passed publisher then emits from the current stream.
startWith(Publisher<? extends O>) - Method in class reactor.rx.Stream
Start emitting all items from the passed publisher then emits from the current stream.
state(boolean, String) - Static method in class reactor.core.support.Assert
Assert a boolean expression, throwing IllegalStateException if the test result is false.
state(boolean) - Static method in class reactor.core.support.Assert
Assert a boolean expression, throwing IllegalStateException if the test result is false.
Status - Class in reactor.io.net.http.model
 
STATUS_CANCELLED - Static variable in class reactor.fn.timer.HashWheelTimer.TimerPausable
 
STATUS_PAUSED - Static variable in class reactor.fn.timer.HashWheelTimer.TimerPausable
 
STATUS_READY - Static variable in class reactor.fn.timer.HashWheelTimer.TimerPausable
 
stop() - Method in class reactor.logback.AsyncAppender
 
store - Variable in class reactor.rx.action.pair.ScanByKeyAction
 
stream(Closure<Action<Event<?>, Event<?>>>) - Method in class reactor.groovy.config.ReactorBuilder
 
stream(String, Closure<Action<Event<?>, Event<?>>>) - Method in class reactor.groovy.config.ReactorBuilder
 
stream(Selector, Closure<Action<Event<?>, Event<?>>>) - Method in class reactor.groovy.config.ReactorBuilder
 
stream() - Method in class reactor.rx.Promise
 
Stream<O> - Class in reactor.rx
Base class for components designed to provide a succinct API for working with future values.
Stream() - Constructor for class reactor.rx.Stream
 
StreamExtensions - Class in reactor.groovy.ext
 
StreamExtensions() - Constructor for class reactor.groovy.ext.StreamExtensions
 
StreamRouter - Class in reactor.groovy.config
 
StreamRouter(Filter, Registry<Object, Processor<Event<?>, Event<?>>>) - Constructor for class reactor.groovy.config.StreamRouter
 
Streams - Class in reactor.rx
A public factory to build Stream, Streams provide for common transformations from a few structures such as Iterable or Future to a Stream, in addition to provide for combinatory operations (merge, switchOnNext...).
Streams() - Constructor for class reactor.rx.Streams
 
StreamStateCallbackAction<T> - Class in reactor.rx.action.passive
 
StreamStateCallbackAction(Consumer<? super Subscriber<? super T>>, Consumer<Void>, Consumer<? super Subscription>) - Constructor for class reactor.rx.action.passive.StreamStateCallbackAction
 
StreamUtils - Class in reactor.rx
A simple collection of utils to assist in various tasks such as Debugging
StreamUtils() - Constructor for class reactor.rx.StreamUtils
 
StreamUtils.StreamVisitor - Class in reactor.rx
 
StreamVisitor(StreamUtils.DebugVisitor) - Constructor for class reactor.rx.StreamUtils.StreamVisitor
 
STRING_CODEC - Static variable in class reactor.io.codec.StandardCodecs
StringCodec - Class in reactor.io.codec
 
StringCodec() - Constructor for class reactor.io.codec.StringCodec
 
StringCodec(Charset) - Constructor for class reactor.io.codec.StringCodec
 
StringCodec(Byte) - Constructor for class reactor.io.codec.StringCodec
 
StringCodec(Byte, Charset) - Constructor for class reactor.io.codec.StringCodec
 
StringCodec.StringEncoder - Class in reactor.io.codec
 
StringEncoder() - Constructor for class reactor.io.codec.StringCodec.StringEncoder
 
submit(Consumer<Long>, long, TimeUnit) - Method in class reactor.bus.timer.EventTimer
 
submit(Consumer<Long>) - Method in class reactor.bus.timer.EventTimer
 
submit(Callable<T>) - Method in class reactor.core.processor.util.SingleUseExecutor
 
submit(Runnable, T) - Method in class reactor.core.processor.util.SingleUseExecutor
 
submit(Runnable) - Method in class reactor.core.processor.util.SingleUseExecutor
 
submit(Consumer<Long>, long, TimeUnit) - Method in class reactor.fn.timer.HashWheelTimer
 
submit(Consumer<Long>) - Method in class reactor.fn.timer.HashWheelTimer
 
submit(Consumer<Long>, long, TimeUnit) - Method in interface reactor.fn.timer.Timer
Submit a task for arbitrary execution after the given time delay.
submit(Consumer<Long>) - Method in interface reactor.fn.timer.Timer
Submit a task for arbitrary execution after the delay of this timer's resolution.
subscribe(Subscriber<? super T>) - Method in class reactor.bus.publisher.BusPublisher
 
subscribe(Subscriber<? super E>) - Method in class reactor.core.processor.RingBufferProcessor
 
subscribe(Subscriber<? super E>) - Method in class reactor.core.processor.RingBufferWorkProcessor
 
subscribe(Subscriber<? super IN>) - Method in class reactor.io.net.impl.netty.http.NettyHttpChannel
 
subscribe(Subscriber<? super IN>) - Method in class reactor.io.net.impl.netty.NettyChannelStream
 
subscribe(Subscriber<? super IN>) - Method in class reactor.io.net.impl.zmq.ZeroMQChannelStream
 
subscribe(Subscriber<? super O>) - Method in class reactor.rx.action.Action
-------------------------------------------------------------------------------------------------------- ACTION SIGNAL HANDLING --------------------------------------------------------------------------------------------------------
subscribe(Subscriber<? super T>) - Method in class reactor.rx.action.combination.ConcatAction
 
subscribe(Subscriber<? super O>) - Method in class reactor.rx.action.combination.DynamicMergeAction
 
subscribe(Subscriber<? super O>) - Method in class reactor.rx.action.combination.FanInAction
 
subscribe(Subscriber<? super T>) - Method in class reactor.rx.action.combination.SwitchAction
 
subscribe(Subscriber<? super O>) - Method in class reactor.rx.action.CompositeAction
 
subscribe(Subscriber<? super Long>) - Method in class reactor.rx.action.metrics.CountAction
 
subscribe(Subscriber<? super Tuple2<K, V>>) - Method in class reactor.rx.action.pair.ScanByKeyAction
 
subscribe(Subscriber<? super T>) - Method in class reactor.rx.action.passive.LoggerAction
 
subscribe(Subscriber<? super T>) - Method in class reactor.rx.action.passive.StreamStateCallbackAction
 
subscribe(Subscription) - Static method in class reactor.rx.action.Signal
Creates and returns a Signal of variety Type.COMPLETE.
subscribe(Subscriber<? super O>) - Method in class reactor.rx.Promise
 
subscribe(Subscriber<? super List<Object>>) - Method in class reactor.rx.stream.BarrierStream
 
subscribe(Subscriber<? super T>) - Method in class reactor.rx.stream.DeferredStream
 
subscribe(Subscriber<? super O>) - Method in class reactor.rx.stream.ErrorStream
 
subscribe(Subscriber<? super T>) - Method in class reactor.rx.stream.FutureStream
 
subscribe(Subscriber<? super MapStream.Signal<K, V>>) - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
subscribe(Subscriber<? super V>) - Method in class reactor.rx.stream.LiftStream
 
subscribe(Subscriber<? super Long>) - Method in class reactor.rx.stream.PeriodicTimerStream
 
subscribe(Subscriber<? super T>) - Method in class reactor.rx.stream.PublisherStream
 
subscribe(Subscriber<? super Long>) - Method in class reactor.rx.stream.SingleTimerStream
 
subscribe(Subscriber<? super T>) - Method in class reactor.rx.stream.SingleValueStream
 
subscribe(CompositeAction<O, A>) - Method in class reactor.rx.Stream
Subscribe the CompositeAction.input() to this Stream.
subscribe(Subscriber<? super T>) - Method in class reactor.rx.stream.SupplierStream
 
subscribeOn(Environment) - Method in class reactor.rx.Stream
Assign a new Dispatcher to handle upstream request to the returned Stream.
subscribeOn(Dispatcher, Subscriber<? super O>) - Method in class reactor.rx.Stream
Assign a new Dispatcher to handle upstream request to the returned Stream.
subscribeOn(Dispatcher) - Method in class reactor.rx.Stream
Assign a new Dispatcher to handle upstream request to the returned Stream.
subscriber - Variable in class reactor.core.reactivestreams.SubscriberBarrier
 
subscriber - Variable in class reactor.core.reactivestreams.SubscriberWithContext
 
subscriber - Variable in class reactor.rx.subscription.PushSubscription
 
SUBSCRIBER_COUNT - Static variable in class reactor.core.processor.ReactorProcessor
 
SubscriberBarrier<I,O> - Class in reactor.core.reactivestreams
A Subscriber with an asymetric typed wrapped subscriber.
SubscriberBarrier(Subscriber<? super O>) - Constructor for class reactor.core.reactivestreams.SubscriberBarrier
 
SubscriberFactory - Class in reactor.core.reactivestreams
A Reactive Streams Subscriber factory which callbacks on start, onNext, onError and shutdown The Publisher will directly forward all the signals passed to the subscribers and complete when onComplete is called.
SubscriberFactory() - Constructor for class reactor.core.reactivestreams.SubscriberFactory
 
SubscriberWithContext<T,C> - Class in reactor.core.reactivestreams
A Subscriber with a typed stateful context.
SubscriberWithContext(C, Subscriber<? super T>) - Constructor for class reactor.core.reactivestreams.SubscriberWithContext
 
subscribeWithSubscription(Subscriber<? super O>, PushSubscription<O>) - Method in class reactor.rx.action.Action
Subscribe a given subscriber and pairs it with a given subscription instead of letting the Stream pick it automatically.
subscribeWithSubscription(Subscriber<? super T>, PushSubscription<T>) - Method in class reactor.rx.action.aggregation.CacheAction
 
subscribeWithSubscription(Subscriber<? super T>, PushSubscription<T>) - Method in class reactor.rx.action.combination.ConcatAction
 
subscribeWithSubscription(Subscriber<? super O>, PushSubscription<O>) - Method in class reactor.rx.broadcast.Broadcaster
 
subscription - Variable in class reactor.core.reactivestreams.SubscriptionWithContext
 
subscription() - Method in class reactor.io.net.impl.netty.NettyChannelHandlerBridge
 
subscription - Variable in class reactor.rx.Promise
 
subscription - Variable in class reactor.rx.subscription.support.WrappedSubscription
 
subscriptions - Variable in class reactor.rx.action.combination.FanInSubscription
 
SubscriptionWithContext<C> - Class in reactor.core.reactivestreams
A Subscription with a typed stateful context.
SubscriptionWithContext(C, Subscription) - Constructor for class reactor.core.reactivestreams.SubscriptionWithContext
 
substring(int, int) - Method in class reactor.io.buffer.Buffer
Slice a portion of this buffer and convert it to a String.
success(T) - Static method in class reactor.rx.Promises
Create a Promise using the given value to complete the Promise immediately.
success() - Static method in class reactor.rx.Promises
Create a Promise already completed without any data.
success(Environment, T) - Static method in class reactor.rx.Promises
Create a Promise using the given value to complete the Promise immediately.
success(Environment, Dispatcher, T) - Static method in class reactor.rx.Promises
Create a Promise using the given value to complete the Promise immediately.
supplier(T) - Static method in class reactor.fn.Functions
Deprecated.
Creates a Supplier that will always return the given value.
supplier(Class<T>) - Static method in class reactor.fn.Functions
Deprecated.
Creates a Supplier that will return a new instance of type each time it's called.
supplier(Callable<T>) - Static method in class reactor.fn.Functions
Deprecated.
Creates a Supplier that will call the callable each time it's asked for a value.
supplier(Future<T>) - Static method in class reactor.fn.Functions
Deprecated.
Creates a Supplier that will get its value from the future each time it's asked for a value.
Supplier<T> - Interface in reactor.fn
Implementations of this class supply the caller with an object.
Suppliers - Class in reactor.fn
Deprecated.
SupplierStream<T> - Class in reactor.rx.stream
A Stream that returns the result from Supplier.get() everytime it is requested via Subscription.request(long).
SupplierStream(Dispatcher, Supplier<? extends T>) - Constructor for class reactor.rx.stream.SupplierStream
 
supply(T) - Static method in class reactor.fn.Suppliers
Deprecated.
Wrap the given object that will supply the given object every time Supplier.get() is called.
supplyOnce(T) - Static method in class reactor.fn.Suppliers
Deprecated.
Supply the given object only once, the first time Supplier.get() is invoked.
supplyWhile(T, Predicate<T>) - Static method in class reactor.fn.Suppliers
Deprecated.
Supply the given object to callers only as long as the given Predicate returns true.
supportsOrdering() - Method in class reactor.core.dispatch.MultiThreadDispatcher
 
supportsOrdering() - Method in class reactor.core.dispatch.SingleThreadDispatcher
 
supportsOrdering() - Method in class reactor.core.dispatch.SynchronousDispatcher
 
supportsOrdering() - Method in class reactor.core.dispatch.TailRecurseDispatcher
 
supportsOrdering() - Method in class reactor.core.dispatch.TraceableDelegatingDispatcher
 
supportsOrdering() - Method in interface reactor.core.Dispatcher
Inspect if the dispatcher supports ordered dispatching: Single threaded dispatchers naturally preserve event ordering on dispatch.
SwitchAction<T> - Class in reactor.rx.action.combination
 
SwitchAction(Dispatcher) - Constructor for class reactor.rx.action.combination.SwitchAction
 
SwitchAction.SwitchSubscriber - Class in reactor.rx.action.combination
 
SWITCHING_PROTOCOLS - Static variable in class reactor.io.net.http.model.Status
101 Switching Protocols
switchMap(Function<? super O, Publisher<? extends V>>) - Method in class reactor.rx.Stream
Assign the given Function to transform the incoming value T into a Stream<O,V> and pass it into another Stream.
switchOnNext() - Static method in class reactor.rx.Streams
Build a Synchronous Action whose data are emitted by the most recent Action.onNext(Object) signaled publisher.
switchOnNext(Dispatcher) - Static method in class reactor.rx.Streams
Build an Action whose data are emitted by the most recent Action.onNext(Object) signaled publisher.
switchOnNext(Publisher<? extends Publisher<? extends T>>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are emitted by the most recent passed publisher.
switchOnNext(Publisher<? extends Publisher<? extends T>>, Dispatcher) - Static method in class reactor.rx.Streams
Build a Stream whose data are emitted by the most recent passed publisher.
SwitchSubscriber(Publisher<? extends T>) - Constructor for class reactor.rx.action.combination.SwitchAction.SwitchSubscriber
 
sync(boolean) - Method in class reactor.io.queue.spec.PersistentQueueSpec
 
synchronousDispatcher() - Method in class reactor.bus.spec.DispatcherComponentSpec
Configures the component to use a synchronous dispatcher
SynchronousDispatcher - Class in reactor.core.dispatch
A Dispatcher implementation that dispatches events using the calling thread.
SynchronousDispatcher() - Constructor for class reactor.core.dispatch.SynchronousDispatcher
 
syncTask(Supplier<T>) - Static method in class reactor.rx.Promises
Create a synchronous Promise producing the value for the Promise using the given supplier.
SyslogCodec - Class in reactor.io.net.codec.syslog
A coded for consuming syslog messages.
SyslogCodec() - Constructor for class reactor.io.net.codec.syslog.SyslogCodec
 
SyslogMessage - Class in reactor.io.net.codec.syslog
An object representation of a syslog message
SyslogMessage(String, int, int, int, Date, String, String) - Constructor for class reactor.io.net.codec.syslog.SyslogMessage
Creates a new syslog message.

T

T(Class<?>) - Static method in class reactor.bus.selector.Selectors
A short-hand alias for Selectors.type(Class).
t1 - Variable in class reactor.fn.tuple.Tuple1
 
t2 - Variable in class reactor.fn.tuple.Tuple2
 
t3 - Variable in class reactor.fn.tuple.Tuple3
 
t4 - Variable in class reactor.fn.tuple.Tuple4
 
t5 - Variable in class reactor.fn.tuple.Tuple5
 
t6 - Variable in class reactor.fn.tuple.Tuple6
 
t7 - Variable in class reactor.fn.tuple.Tuple7
 
t8 - Variable in class reactor.fn.tuple.Tuple8
 
tailRecurse() - Static method in class reactor.Environment
Obtain a fresh tailRecurse Dispatcher.
TailRecurseDispatcher - Class in reactor.core.dispatch
A Dispatcher implementation that trampolines events using the calling thread and.
TailRecurseDispatcher() - Constructor for class reactor.core.dispatch.TailRecurseDispatcher
 
tailRecurseSeq - Variable in class reactor.core.dispatch.SingleThreadDispatcher
 
tailRecursionPile - Variable in class reactor.core.dispatch.SingleThreadDispatcher
 
tailRecursionPileSize - Variable in class reactor.core.dispatch.SingleThreadDispatcher
 
take() - Method in class reactor.core.queue.CompletableBlockingQueue
 
take(long) - Method in class reactor.rx.Stream
Create a new Stream that will signal next elements up to times.
take(long, TimeUnit) - Method in class reactor.rx.Stream
Create a new Stream that will signal next elements up to the specified .
take(long, TimeUnit, Timer) - Method in class reactor.rx.Stream
Create a new Stream that will signal next elements up to the specified .
TakeAction<T> - Class in reactor.rx.action.filter
 
TakeAction(long) - Constructor for class reactor.rx.action.filter.TakeAction
 
TakeUntilTimeout<T> - Class in reactor.rx.action.filter
 
TakeUntilTimeout(Dispatcher, long, TimeUnit, Timer) - Constructor for class reactor.rx.action.filter.TakeUntilTimeout
 
takeWhile(Predicate<O>) - Method in class reactor.rx.Stream
Create a new Stream that will signal next elements while is true.
TakeWhileAction<T> - Class in reactor.rx.action.filter
 
TakeWhileAction(Predicate<T>) - Constructor for class reactor.rx.action.filter.TakeWhileAction
 
Tap<T> - Class in reactor.fn.support
A Tap provides a limited window into an event stream.
Tap() - Constructor for class reactor.fn.support.Tap
Create a Tap.
tap() - Method in class reactor.rx.Stream
Create a Tap that maintains a reference to the last value seen by this Stream.
TapAndControls<O> - Class in reactor.rx.action.support
 
TapAndControls(Tap<? extends O>, Control) - Constructor for class reactor.rx.action.support.TapAndControls
 
Task() - Constructor for class reactor.core.dispatch.AbstractLifecycleDispatcher.Task
 
task(Environment, Supplier<T>) - Static method in class reactor.rx.Promises
Create a Promise producing the value for the Promise using the given supplier.
task(Environment, Dispatcher, Supplier<T>) - Static method in class reactor.rx.Promises
Create a Promise producing the value for the Promise using the given supplier.
tcpClient() - Static method in class reactor.io.net.NetStreams
Bind a new TCP client to the localhost on port 12012.
tcpClient(String) - Static method in class reactor.io.net.NetStreams
Bind a new TCP client to the specified connect address and port 12012.
tcpClient(int) - Static method in class reactor.io.net.NetStreams
Bind a new TCP client to "loopback" on the the specified port.
tcpClient(String, int) - Static method in class reactor.io.net.NetStreams
Bind a new TCP client to the specified connect address and port.
tcpClient(Function<? super Spec.TcpClientSpec<IN, OUT>, ? extends Spec.TcpClientSpec<IN, OUT>>) - Static method in class reactor.io.net.NetStreams
Bind a new TCP client to the specified connect address and port.
tcpClient(Class<? extends TcpClient>, Function<? super Spec.TcpClientSpec<IN, OUT>, ? extends Spec.TcpClientSpec<IN, OUT>>) - Static method in class reactor.io.net.NetStreams
Bind a new TCP client to the specified connect address and port.
TcpClient<IN,OUT> - Class in reactor.io.net.tcp
The base class for a Reactor-based TCP client.
TcpClient(Environment, Dispatcher, Supplier<InetSocketAddress>, ClientSocketOptions, SslOptions, Codec<Buffer, IN, OUT>) - Constructor for class reactor.io.net.tcp.TcpClient
 
tcpNoDelay() - Method in class reactor.io.net.config.CommonSocketOptions
Returns a boolean indicating whether or not TCP_NODELAY is enabled
tcpNoDelay(boolean) - Method in class reactor.io.net.config.CommonSocketOptions
Enables or disables TCP_NODELAY
tcpServer() - Static method in class reactor.io.net.NetStreams
Bind a new TCP server to "loopback" on port 12012.
tcpServer(int) - Static method in class reactor.io.net.NetStreams
Bind a new TCP server to "loopback" on the given port.
tcpServer(String) - Static method in class reactor.io.net.NetStreams
Bind a new TCP server to the given bind address on port 12012.
tcpServer(String, int) - Static method in class reactor.io.net.NetStreams
Bind a new TCP server to the given bind address and port.
tcpServer(Function<? super Spec.TcpServerSpec<IN, OUT>, ? extends Spec.TcpServerSpec<IN, OUT>>) - Static method in class reactor.io.net.NetStreams
Bind a new TCP server to the specified bind address and port.
tcpServer(Class<? extends TcpServer>, Function<? super Spec.TcpServerSpec<IN, OUT>, ? extends Spec.TcpServerSpec<IN, OUT>>) - Static method in class reactor.io.net.NetStreams
Bind a new TCP server to the specified bind address and port.
TcpServer<IN,OUT> - Class in reactor.io.net.tcp
Base functionality needed by all servers that communicate with clients over TCP.
TcpServer(Environment, Dispatcher, InetSocketAddress, ServerSocketOptions, SslOptions, Codec<Buffer, IN, OUT>) - Constructor for class reactor.io.net.tcp.TcpServer
 
TE - Static variable in interface reactor.io.net.http.model.HttpHeaders
The HTTP TE header field name.
TEMPORARY_REDIRECT - Static variable in class reactor.io.net.http.model.Status
307 Temporary Redirect (since HTTP/1.1)
TERMINAL_UPDATER - Static variable in class reactor.core.reactivestreams.SubscriberWithContext
 
TERMINAL_UPDATER - Static variable in class reactor.rx.subscription.PushSubscription
 
terminate() - Static method in class reactor.Environment
Clean and Shutdown the context environment.
terminate() - Method in class reactor.rx.subscription.PushSubscription
 
terminated - Variable in class reactor.rx.action.combination.FanInSubscription
 
terminated - Variable in class reactor.rx.subscription.PushSubscription
 
TERMINATED_UPDATER - Static variable in class reactor.core.reactivestreams.SubscriptionWithContext
 
test(K) - Method in class reactor.bus.selector.ObjectSelector
 
test(T) - Method in interface reactor.fn.Predicate
Returns true if the input object matches some criteria.
test(V) - Method in class reactor.groovy.support.ClosurePredicate
 
THREAD_POOL - Static variable in class reactor.Environment
The name of the default thread pool dispatcher
ThreadPoolExecutorDispatcher - Class in reactor.core.dispatch
A Dispatcher that uses a ThreadPoolExecutor with an unbounded queue to dispatch events.
ThreadPoolExecutorDispatcher(int, int) - Constructor for class reactor.core.dispatch.ThreadPoolExecutorDispatcher
Creates a new ThreadPoolExecutorDispatcher with the given poolSize and backlog.
ThreadPoolExecutorDispatcher(int, int, String) - Constructor for class reactor.core.dispatch.ThreadPoolExecutorDispatcher
Create a new ThreadPoolExecutorDispatcher with the given size, backlog, name, and RejectedExecutionHandler.
ThreadPoolExecutorDispatcher(int, int, String, BlockingQueue<Runnable>, RejectedExecutionHandler) - Constructor for class reactor.core.dispatch.ThreadPoolExecutorDispatcher
Create a new ThreadPoolExecutorDispatcher with the given size, backlog, name, and RejectedExecutionHandler.
ThreadPoolExecutorDispatcher(int, int, ExecutorService) - Constructor for class reactor.core.dispatch.ThreadPoolExecutorDispatcher
Create a new ThreadPoolTaskExecutor with the given backlog and ExecutorService.
throttle(long) - Method in class reactor.rx.Stream
Request once the parent stream every milliseconds.
throttle(long, Timer) - Method in class reactor.rx.Stream
Request once the parent stream every milliseconds after an initial .
ThrottleRequestAction<T> - Class in reactor.rx.action.control
 
ThrottleRequestAction(Dispatcher, Timer, long) - Constructor for class reactor.rx.action.control.ThrottleRequestAction
 
ThrottleRequestWhenAction<T> - Class in reactor.rx.action.control
 
ThrottleRequestWhenAction(Dispatcher, Function<? super Stream<? extends Long>, ? extends Publisher<? extends Long>>) - Constructor for class reactor.rx.action.control.ThrottleRequestWhenAction
 
throwIfFatal(Throwable) - Static method in class reactor.core.support.Exceptions
Throws a particular Throwable only if it belongs to a set of "fatal" error varieties.
timeout() - Method in class reactor.io.net.config.CommonSocketOptions
Gets the SO_TIMEOUT value
timeout(int) - Method in class reactor.io.net.config.CommonSocketOptions
Set the SO_TIMEOUT value.
timeout(long) - Method in class reactor.rx.Stream
Signal an error if no data has been emitted for milliseconds.
timeout(long, TimeUnit) - Method in class reactor.rx.Stream
Signal an error if no data has been emitted for milliseconds.
timeout(long, TimeUnit, Publisher<? extends O>) - Method in class reactor.rx.Stream
Switch to the fallback Publisher if no data has been emitted for milliseconds.
timeout(long, TimeUnit, Publisher<? extends O>, Timer) - Method in class reactor.rx.Stream
Signal an error if no data has been emitted for milliseconds.
TimeoutAction<T> - Class in reactor.rx.action.error
 
TimeoutAction(Dispatcher, Publisher<? extends T>, Timer, long) - Constructor for class reactor.rx.action.error.TimeoutAction
 
timer() - Static method in class reactor.Environment
Obtain the default timer from the current environment.
Timer - Interface in reactor.fn.timer
 
timer - Variable in class reactor.rx.action.aggregation.BatchAction
 
timer(long) - Static method in class reactor.rx.Streams
Build a Stream that will only emit 0l after the time delay and then complete.
timer(Timer, long) - Static method in class reactor.rx.Streams
Build a Stream that will only emit 0l after the time delay and then complete.
timer(long, TimeUnit) - Static method in class reactor.rx.Streams
Build a Stream that will only emit 0l after the time delay and then complete.
timer(Timer, long, TimeUnit) - Static method in class reactor.rx.Streams
Build a Stream that will only emit 0l after the time delay and then complete.
TimerPausable(long, long, T, long) - Constructor for class reactor.fn.timer.HashWheelTimer.TimerPausable
Creates a new Timer Registration with given , and .
timespan - Variable in class reactor.rx.action.aggregation.BatchAction
 
timestamp() - Method in class reactor.rx.Stream
Create a new Stream that accepts a Tuple2 of T1 Long system time in millis and T2 associated data
TimestampAction<T> - Class in reactor.rx.action.metrics
 
TimestampAction() - Constructor for class reactor.rx.action.metrics.TimestampAction
 
TimeUtils - Class in reactor.fn.timer
 
TimeUtils() - Constructor for class reactor.fn.timer.TimeUtils
 
toArray() - Method in class reactor.core.queue.internal.MpscLinkedQueue
 
toArray(T[]) - Method in class reactor.core.queue.internal.MpscLinkedQueue
 
toArray() - Method in class reactor.fn.tuple.Tuple
Turn this Tuple into a plain Object array.
toArray() - Method in class reactor.fn.tuple.Tuple1
 
toArray() - Method in class reactor.fn.tuple.Tuple2
 
toArray() - Method in class reactor.fn.tuple.Tuple3
 
toArray() - Method in class reactor.fn.tuple.Tuple4
 
toArray() - Method in class reactor.fn.tuple.Tuple5
 
toArray() - Method in class reactor.fn.tuple.Tuple6
 
toArray() - Method in class reactor.fn.tuple.Tuple7
 
toArray() - Method in class reactor.fn.tuple.Tuple8
 
toArray() - Method in class reactor.fn.tuple.TupleN
 
toBlockingQueue() - Method in class reactor.rx.Stream
Blocking call to pass values from this stream to the queue that can be polled from a consumer.
toBlockingQueue(int) - Method in class reactor.rx.Stream
Blocking call to eagerly fetch values from this stream
toBroadcastCompleteConsumer() - Method in class reactor.rx.action.Action
Create a consumer that broadcast complete signal from any accepted value.
toBroadcastErrorConsumer() - Method in class reactor.rx.action.Action
Create a consumer that broadcast error signal from any accepted value.
toBroadcastNextConsumer() - Method in class reactor.rx.action.Action
Create a consumer that broadcast next signal from accepted values.
toList() - Method in class reactor.rx.Stream
Fetch all values in a List to the returned Promise
toList(long) - Method in class reactor.rx.Stream
Return the promise of N signals collected into an array list.
toMap() - Method in class reactor.rx.StreamUtils.StreamVisitor
 
TOO_MANY_REQUESTS - Static variable in class reactor.io.net.http.model.Status
429 Too Many Requests (RFC6585)
toString() - Method in class reactor.alloc.AbstractReference
 
toString() - Method in class reactor.alloc.RecyclableString
 
toString() - Method in class reactor.bus.Event.Headers
 
toString() - Method in class reactor.bus.Event
 
toString() - Method in class reactor.bus.publisher.BusPublisher
 
toString() - Method in class reactor.bus.registry.CachableRegistration
 
toString() - Method in class reactor.bus.selector.ObjectSelector
 
toString() - Method in class reactor.core.dispatch.AbstractLifecycleDispatcher
 
toString() - Method in class reactor.core.dispatch.SynchronousDispatcher
 
toString() - Method in class reactor.core.dispatch.TailRecurseDispatcher
 
toString() - Method in class reactor.core.processor.RingBufferProcessor
 
toString() - Method in class reactor.core.processor.RingBufferWorkProcessor
 
toString() - Method in class reactor.core.reactivestreams.SerializedSubscriber
 
toString() - Method in class reactor.fn.timer.HashWheelTimer.TimerPausable
 
toString() - Method in class reactor.fn.timer.HashWheelTimer
 
toString() - Method in class reactor.fn.tuple.Tuple1
 
toString() - Method in class reactor.fn.tuple.Tuple2
 
toString() - Method in class reactor.fn.tuple.Tuple3
 
toString() - Method in class reactor.fn.tuple.Tuple4
 
toString() - Method in class reactor.fn.tuple.Tuple5
 
toString() - Method in class reactor.fn.tuple.Tuple6
 
toString() - Method in class reactor.fn.tuple.Tuple7
 
toString() - Method in class reactor.fn.tuple.Tuple8
 
toString() - Method in class reactor.fn.tuple.TupleN
 
toString() - Method in class reactor.io.buffer.Buffer
 
toString() - Method in class reactor.io.net.codec.syslog.SyslogMessage
 
toString() - Method in enum reactor.io.net.http.model.Protocol
 
toString() - Method in class reactor.io.net.http.model.Status
 
toString() - Method in enum reactor.io.net.http.model.Transfer
 
toString() - Method in class reactor.io.net.impl.netty.NettyChannelStream
 
toString() - Method in class reactor.io.net.impl.zmq.ZeroMQChannelStream
 
toString() - Method in class reactor.rx.action.Action
 
toString() - Method in class reactor.rx.action.aggregation.BatchAction
 
toString() - Method in class reactor.rx.action.aggregation.BufferShiftAction
 
toString() - Method in class reactor.rx.action.aggregation.SampleAction
 
toString() - Method in class reactor.rx.action.combination.CombineLatestAction.InnerSubscriber
 
toString() - Method in class reactor.rx.action.combination.CombineLatestAction
 
toString() - Method in class reactor.rx.action.combination.DynamicMergeAction
 
toString() - Method in class reactor.rx.action.combination.FanInAction.InnerSubscriber
 
toString() - Method in class reactor.rx.action.combination.FanInAction
 
toString() - Method in class reactor.rx.action.combination.FanInSubscription
 
toString() - Method in class reactor.rx.action.combination.MergeAction.InnerSubscriber
 
toString() - Method in class reactor.rx.action.combination.ZipAction.InnerSubscriber
 
toString() - Method in class reactor.rx.action.combination.ZipAction
 
toString() - Method in class reactor.rx.action.combination.ZipAction.Zippable
 
toString() - Method in class reactor.rx.action.CompositeAction
 
toString() - Method in class reactor.rx.action.control.DispatcherAction
 
toString() - Method in class reactor.rx.action.error.ErrorAction
 
toString() - Method in class reactor.rx.action.error.ErrorReturnAction
 
toString() - Method in class reactor.rx.action.error.ErrorWithValueAction
 
toString() - Method in class reactor.rx.action.error.IgnoreErrorAction
 
toString() - Method in class reactor.rx.action.filter.SkipAction
 
toString() - Method in class reactor.rx.action.filter.SkipUntilTimeout
 
toString() - Method in class reactor.rx.action.filter.TakeAction
 
toString() - Method in class reactor.rx.action.filter.TakeUntilTimeout
 
toString() - Method in class reactor.rx.action.filter.TakeWhileAction
 
toString() - Method in class reactor.rx.action.passive.LoggerAction
 
toString() - Method in class reactor.rx.action.Signal
 
toString() - Method in class reactor.rx.action.terminal.AdaptiveConsumerAction
 
toString() - Method in class reactor.rx.action.terminal.ConsumerAction
 
toString() - Method in class reactor.rx.Promise
 
toString() - Method in class reactor.rx.stream.ErrorStream
 
toString() - Method in class reactor.rx.stream.GroupedStream
 
toString() - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
toString() - Method in class reactor.rx.stream.LiftStream
 
toString() - Method in class reactor.rx.stream.MapStream.Signal
 
toString() - Method in class reactor.rx.stream.PeriodicTimerStream
 
toString() - Method in class reactor.rx.stream.SingleTimerStream
 
toString() - Method in class reactor.rx.stream.SingleValueStream
 
toString() - Method in class reactor.rx.Stream
 
toString() - Method in class reactor.rx.StreamUtils.StreamVisitor
 
toString() - Method in class reactor.rx.subscription.DropSubscription
 
toString() - Method in class reactor.rx.subscription.PushSubscription
 
toString() - Method in class reactor.rx.subscription.ReactiveSubscription
 
toString() - Method in class reactor.rx.subscription.support.WrappedSubscription
 
TRACE - Static variable in class reactor.io.net.http.model.Method
 
TRACE_CANCEL - Static variable in exception reactor.core.processor.CancelException
 
TRACE_NOCAPACITY - Static variable in exception reactor.core.processor.InsufficientCapacityException
 
TraceableDelegatingDispatcher - Class in reactor.core.dispatch
An implementation of Dispatcher that traces activity through it.
TraceableDelegatingDispatcher(Dispatcher) - Constructor for class reactor.core.dispatch.TraceableDelegatingDispatcher
 
TraceableDelegatingFilter - Class in reactor.bus.filter
 
TraceableDelegatingFilter(Filter) - Constructor for class reactor.bus.filter.TraceableDelegatingFilter
 
TraceableDelegatingRouter - Class in reactor.bus.routing
 
TraceableDelegatingRouter(Router) - Constructor for class reactor.bus.routing.TraceableDelegatingRouter
 
traceEventPath() - Method in class reactor.bus.spec.EventRoutingComponentSpec
Configures this component to provide event tracing when dispatching and routing an event.
traceEventPath(boolean) - Method in class reactor.bus.spec.EventRoutingComponentSpec
Configures this component to provide or not provide event tracing when dispatching and routing an event.
TRAILER - Static variable in interface reactor.io.net.http.model.ResponseHeaders
The HTTP Trailer header field name.
transfer() - Method in class reactor.io.net.http.HttpChannel
 
transfer(Transfer) - Method in class reactor.io.net.http.HttpChannel
Define the Transfer mode for this http connection
Transfer - Enum in reactor.io.net.http.model
 
transfer() - Method in class reactor.io.net.impl.netty.http.NettyHttpChannel
 
transfer(Transfer) - Method in class reactor.io.net.impl.netty.http.NettyHttpChannel
 
TRANSFER_ENCODING - Static variable in interface reactor.io.net.http.model.ResponseHeaders
The HTTP Transfer-Encoding header field name.
transferEncodingChunked() - Method in interface reactor.io.net.http.model.WritableHeaders
 
transferEncodingChunked() - Method in class reactor.io.net.impl.netty.http.NettyHttpHeaders
 
transferEncodingChunked() - Method in class reactor.io.net.impl.netty.http.NettyHttpResponseHeaders
 
trustManagerFactoryAlgorithm() - Method in class reactor.io.net.config.SslOptions
 
trustManagerFactoryAlgorithm(String) - Method in class reactor.io.net.config.SslOptions
 
trustManagerPasswd() - Method in class reactor.io.net.config.SslOptions
 
trustManagerPasswd(String) - Method in class reactor.io.net.config.SslOptions
 
trustManagers() - Method in class reactor.io.net.config.SslOptions
 
trustManagers(Supplier<TrustManager[]>) - Method in class reactor.io.net.config.SslOptions
 
tryAllocateTask() - Method in class reactor.core.dispatch.AbstractLifecycleDispatcher
 
tryAllocateTask() - Method in class reactor.core.dispatch.MpscDispatcher
 
tryAllocateTask() - Method in class reactor.core.dispatch.MultiThreadDispatcher
 
tryAllocateTask() - Method in class reactor.core.dispatch.RingBufferDispatcher
 
tryAllocateTask() - Method in class reactor.core.dispatch.WorkQueueDispatcher
 
tryDispatch(E, Consumer<E>, Consumer<Throwable>) - Method in class reactor.core.dispatch.AbstractLifecycleDispatcher
 
tryDispatch(E, Consumer<E>, Consumer<Throwable>) - Method in class reactor.core.dispatch.SynchronousDispatcher
 
tryDispatch(E, Consumer<E>, Consumer<Throwable>) - Method in class reactor.core.dispatch.TailRecurseDispatcher
 
tryDispatch(E, Consumer<E>, Consumer<Throwable>) - Method in class reactor.core.dispatch.TraceableDelegatingDispatcher
 
tryDispatch(E, Consumer<E>, Consumer<Throwable>) - Method in interface reactor.core.Dispatcher
Instruct the Dispatcher to dispatch the data.
Tuple - Class in reactor.fn.tuple
A Tuple is an immutable Collection of objects, each of which can be of an arbitrary type.
Tuple(int) - Constructor for class reactor.fn.tuple.Tuple
Creates a new Tuple that holds the given values.
Tuple1<T1> - Class in reactor.fn.tuple
A tuple that holds a single value
Tuple2<T1,T2> - Class in reactor.fn.tuple
A tuple that holds two values
Tuple3<T1,T2,T3> - Class in reactor.fn.tuple
A tuple that holds three values
Tuple4<T1,T2,T3,T4> - Class in reactor.fn.tuple
A tuple that holds four values
Tuple5<T1,T2,T3,T4,T5> - Class in reactor.fn.tuple
A tuple that holds five values
Tuple6<T1,T2,T3,T4,T5,T6> - Class in reactor.fn.tuple
A tuple that holds six values
Tuple7<T1,T2,T3,T4,T5,T6,T7> - Class in reactor.fn.tuple
A tuple that holds seven values
Tuple8<T1,T2,T3,T4,T5,T6,T7,T8> - Class in reactor.fn.tuple
A tuple that holds eight values
TupleN - Class in reactor.fn.tuple
A tuple that holds 9 or more values
type(Class<?>) - Static method in class reactor.bus.selector.Selectors
Creates a Selector based on the given class type that matches objects whose type is assignable according to Class.isAssignableFrom(Class).
type - Variable in class reactor.core.processor.MutableSignal
 
typeSelector(Class<?>) - Static method in class reactor.bus.selector.ClassSelector
Creates a ClassSelector based on the given class type that only matches if the key being matched is assignable according to Class.isAssignableFrom(Class).

U

U(String) - Static method in class reactor.bus.selector.Selectors
A short-hand alias for Selectors.uri(String).
udpServer() - Static method in class reactor.io.net.NetStreams
Bind a new UDP server to the "loopback" address.
udpServer(String) - Static method in class reactor.io.net.NetStreams
Bind a new UDP server to the given bind address.
udpServer(int) - Static method in class reactor.io.net.NetStreams
Bind a new UDP server to the "loopback" address and specified port.
udpServer(String, int) - Static method in class reactor.io.net.NetStreams
Bind a new UDP server to the given bind address and port.
udpServer(Function<? super Spec.DatagramServerSpec<IN, OUT>, ? extends Spec.DatagramServerSpec<IN, OUT>>) - Static method in class reactor.io.net.NetStreams
Bind a new UDP server to the specified bind address and port.
udpServer(Class<? extends DatagramServer>, Function<? super Spec.DatagramServerSpec<IN, OUT>, ? extends Spec.DatagramServerSpec<IN, OUT>>) - Static method in class reactor.io.net.NetStreams
Bind a new UDP server to the specified bind address and port.
UNAUTHORIZED - Static variable in class reactor.io.net.http.model.Status
401 Unauthorized
unbounded() - Static method in class reactor.core.reactivestreams.SubscriberFactory
Create a Subscriber that will will automatically request Long.MAX_VALUE onSubscribe.
unbounded(BiConsumer<T, SubscriptionWithContext<Void>>) - Static method in class reactor.core.reactivestreams.SubscriberFactory
Create a Subscriber reacting onNext.
unbounded(BiConsumer<T, SubscriptionWithContext<Void>>, Consumer<Throwable>) - Static method in class reactor.core.reactivestreams.SubscriberFactory
Create a Subscriber reacting onNext and onError.
unbounded(BiConsumer<T, SubscriptionWithContext<Void>>, Consumer<Throwable>, Consumer<Void>) - Static method in class reactor.core.reactivestreams.SubscriberFactory
Create a Subscriber reacting onNext, onError and onComplete.
unbounded() - Method in class reactor.rx.Stream
Make this Stream subscribers unbounded
uncaughtErrorHandler(Consumer<Throwable>) - Method in class reactor.bus.spec.EventRoutingComponentSpec
Configures the component's uncaught error handler for any errors that get reported into this component but aren't a direct result of dispatching (e.g. errors that originate from another component).
unit - Variable in class reactor.rx.action.aggregation.BatchAction
 
UNORDERED_COLLECTION - Static variable in class reactor.io.net.http.model.Status
425 Unordered Collection (WebDAV, RFC3648)
UNPROCESSABLE_ENTITY - Static variable in class reactor.io.net.http.model.Status
422 Unprocessable Entity (WebDAV, RFC4918)
unregister(K) - Method in class reactor.bus.registry.CachingRegistry
 
unregister(K) - Method in interface reactor.bus.registry.Registry
Remove any objects matching this key.
unregister(Object) - Method in class reactor.bus.registry.SimpleCachingRegistry
 
UNSUPPORTED_MEDIA_TYPE - Static variable in class reactor.io.net.http.model.Status
415 Unsupported Media Type
updatePendingRequests(long) - Method in class reactor.rx.subscription.PushSubscription
 
updatePendingRequests(long) - Method in class reactor.rx.subscription.ReactiveSubscription
 
updatePendingRequests(long) - Method in class reactor.rx.subscription.support.WrappedSubscription
 
UPGRADE - Static variable in interface reactor.io.net.http.model.Headers
The HTTP Upgrade header field name.
UPGRADE_REQUIRED - Static variable in class reactor.io.net.http.model.Status
426 Upgrade Required (RFC2817)
upstreamSubscription - Variable in class reactor.core.processor.ReactorProcessor
 
upstreamSubscription - Variable in class reactor.rx.action.Action
The upstream request tracker to avoid dispatcher overrun, based on the current this#capacity
uri(String) - Static method in class reactor.bus.selector.Selectors
Creates a Selector based on a URI template.
uri() - Method in class reactor.io.net.http.HttpChannel
 
uri() - Method in class reactor.io.net.impl.netty.http.NettyHttpChannel
 
UriPathSelector - Class in reactor.bus.selector
A Selector implementation based on a UriPathTemplate.
UriPathSelector(String) - Constructor for class reactor.bus.selector.UriPathSelector
Create a selector from the given uri template string.
uriPathSelector(String) - Static method in class reactor.bus.selector.UriPathSelector
Creates a Selector based on a URI template.
uriPathSelector - Variable in class reactor.io.net.http.HttpSelector
 
UriPathTemplate - Class in reactor.bus.selector
Represents a URI template.
UriPathTemplate(String) - Constructor for class reactor.bus.selector.UriPathTemplate
Creates a new UriPathTemplate from the given uriPattern.
UriSelector - Class in reactor.bus.selector
A Selector implementation that matches on various components of a full URI.
UriSelector(String) - Constructor for class reactor.bus.selector.UriSelector
 
UriSelector(URI) - Constructor for class reactor.bus.selector.UriSelector
 
USE_PROXY - Static variable in class reactor.io.net.http.model.Status
305 Use Proxy (since HTTP/1.1)
USER_AGENT - Static variable in interface reactor.io.net.http.model.HttpHeaders
The HTTP User-Agent header field name.
userEventTriggered(ChannelHandlerContext, Object) - Method in class reactor.io.net.impl.netty.NettyChannelHandlerBridge
 
UUIDUtils - Class in reactor.core.support
Helper for creating random and Type 1 (time-based) UUIDs.

V

value - Variable in class reactor.core.processor.MutableSignal
 
value() - Method in class reactor.core.queue.internal.MpscLinkedQueueNode
 
value(V) - Method in class reactor.rx.stream.MapStream.MutableSignal
 
value() - Method in class reactor.rx.stream.MapStream.Signal
 
valueAccepted(O) - Method in class reactor.rx.Promise
 
ValueCause(Object) - Constructor for exception reactor.core.support.Exceptions.ValueCause
Create a CauseValue exception and include in its error message a string representation of the item that was intended to be emitted at the time the exception was handled.
valueCodec - Variable in class reactor.rx.stream.io.ChronicleReaderStream
 
valueCodec() - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
valueOf(String) - Static method in enum reactor.bus.spec.EventRoutingComponentSpec.EventRoutingStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum reactor.core.config.DispatcherType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum reactor.core.processor.MutableSignal.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum reactor.io.codec.FrameCodec.LengthField
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum reactor.io.net.http.model.Protocol
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in class reactor.io.net.http.model.Status
Returns the Status represented by the specified code.
valueOf(String) - Static method in enum reactor.io.net.http.model.Transfer
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum reactor.rx.action.Signal.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum reactor.rx.Promise.FinalState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum reactor.rx.stream.MapStream.Operation
Returns the enum constant of this type with the specified name.
values() - Static method in enum reactor.bus.spec.EventRoutingComponentSpec.EventRoutingStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum reactor.core.config.DispatcherType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum reactor.core.processor.MutableSignal.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum reactor.io.codec.FrameCodec.LengthField
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum reactor.io.net.http.model.Protocol
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum reactor.io.net.http.model.Transfer
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum reactor.rx.action.Signal.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum reactor.rx.Promise.FinalState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
values() - Static method in enum reactor.rx.stream.MapStream.Operation
Returns an array containing the constants of this enum type, in the order they are declared.
VARIANT_ALSO_NEGOTIATES - Static variable in class reactor.io.net.http.model.Status
506 Variant Also Negotiates (RFC2295)
VARY - Static variable in interface reactor.io.net.http.model.ResponseHeaders
The HTTP Vary header field name.
VIA - Static variable in interface reactor.io.net.http.model.ResponseHeaders
The HTTP Via header field name.

W

waitFor(long, Sequence, Sequence, SequenceBarrier) - Method in class reactor.core.dispatch.wait.AgileWaitingStrategy
 
waitFor(long, Sequence, Sequence, SequenceBarrier) - Method in class reactor.core.dispatch.wait.ParkWaitStrategy
 
WaitingMood - Interface in reactor.core.dispatch.wait
A Component with some waiting capacities such as Dispatcher that uses a CPU-friendly strategy (e.g. blocking wait) and a CPU-starving strategy (e.g.
waitRequestOrTerminalEvent(Sequence, RingBuffer<MutableSignal<T>>, SequenceBarrier, Subscriber<? super T>, AtomicBoolean) - Static method in class reactor.core.processor.util.RingBufferSubscriberUtils
 
waitUntil(long) - Method in class reactor.fn.timer.HashWheelTimer.BusySpinWait
 
waitUntil(long) - Method in class reactor.fn.timer.HashWheelTimer.SleepWait
 
waitUntil(long) - Method in interface reactor.fn.timer.HashWheelTimer.WaitStrategy
Wait until the given deadline,
waitUntil(long) - Method in class reactor.fn.timer.HashWheelTimer.YieldingWait
 
WARNING - Static variable in interface reactor.io.net.http.model.Headers
The HTTP Warning header field name.
when(Promise<T1>, Promise<T2>) - Static method in class reactor.rx.Promises
Merge given promises into a new a Promise that will be fulfilled when all of the given Promise Promises have been fulfilled.
when(Promise<T1>, Promise<T2>, Promise<T3>) - Static method in class reactor.rx.Promises
Merge given promises into a new a Promise that will be fulfilled when all of the given Promise Promises have been fulfilled.
when(Promise<T1>, Promise<T2>, Promise<T3>, Promise<T4>) - Static method in class reactor.rx.Promises
Merge given promises into a new a Promise that will be fulfilled when all of the given Promise Promises have been fulfilled.
when(Promise<T1>, Promise<T2>, Promise<T3>, Promise<T4>, Promise<T5>) - Static method in class reactor.rx.Promises
Merge given promises into a new a Promise that will be fulfilled when all of the given Promise Promises have been fulfilled.
when(Promise<T1>, Promise<T2>, Promise<T3>, Promise<T4>, Promise<T5>, Promise<T6>) - Static method in class reactor.rx.Promises
Merge given promises into a new a Promise that will be fulfilled when all of the given Promise Promises have been fulfilled.
when(Promise<T1>, Promise<T2>, Promise<T3>, Promise<T4>, Promise<T5>, Promise<T6>, Promise<T7>) - Static method in class reactor.rx.Promises
Merge given promises into a new a Promise that will be fulfilled when all of the given Promise Promises have been fulfilled.
when(Promise<T1>, Promise<T2>, Promise<T3>, Promise<T4>, Promise<T5>, Promise<T6>, Promise<T7>, Promise<T8>) - Static method in class reactor.rx.Promises
Merge given promises into a new a Promise that will be fulfilled when all of the given Promise Promises have been fulfilled.
when(List<? extends Promise<T>>) - Static method in class reactor.rx.Promises
Aggregate given promises into a new a Promise that will be fulfilled when all of the given Promise Promises have been fulfilled.
when(Class<E>, Consumer<E>) - Method in class reactor.rx.Stream
Assign an error handler to exceptions of the given type.
window() - Method in class reactor.rx.Stream
Re-route incoming values into a dynamically created Stream every pre-defined Stream.getCapacity() times.
window(int) - Method in class reactor.rx.Stream
Re-route incoming values into a dynamically created Stream every pre-defined times.
window(int, int) - Method in class reactor.rx.Stream
Re-route incoming values into bucket streams that will be pushed into the returned Stream every skip and complete every time maxSize has been reached by any of them.
window(Supplier<? extends Publisher<?>>) - Method in class reactor.rx.Stream
Re-route incoming values into bucket streams that will be pushed into the returned Stream every and complete every time boundarySupplier stream emits an item.
window(Publisher<?>, Supplier<? extends Publisher<?>>) - Method in class reactor.rx.Stream
Re-route incoming values into bucket streams that will be pushed into the returned Stream every and complete every time boundarySupplier stream emits an item.
window(long, TimeUnit) - Method in class reactor.rx.Stream
Re-route incoming values into a dynamically created Stream every pre-defined timespan.
window(long, TimeUnit, Timer) - Method in class reactor.rx.Stream
Re-route incoming values into a dynamically created Stream every pre-defined timespan.
window(int, long, TimeUnit) - Method in class reactor.rx.Stream
Re-route incoming values into a dynamically created Stream every pre-defined timespan OR maxSize items.
window(int, long, TimeUnit, Timer) - Method in class reactor.rx.Stream
Re-route incoming values into a dynamically created Stream every pre-defined timespan OR maxSize items.
window(long, long, TimeUnit) - Method in class reactor.rx.Stream
Re-route incoming values into bucket streams that will be pushed into the returned Stream every timeshift period.
window(long, long, TimeUnit, Timer) - Method in class reactor.rx.Stream
Re-route incoming values into bucket streams that will be pushed into the returned Stream every timeshift period.
WindowAction<T> - Class in reactor.rx.action.aggregation
WindowAction is forwarding events on a steam until is reached, after that streams collected events further, complete it and create a fresh new stream.
WindowAction(Environment, Dispatcher, int) - Constructor for class reactor.rx.action.aggregation.WindowAction
 
WindowAction(Environment, Dispatcher, int, long, TimeUnit, Timer) - Constructor for class reactor.rx.action.aggregation.WindowAction
 
WindowShiftAction<T> - Class in reactor.rx.action.aggregation
WindowAction is forwarding events on a steam until is reached, after that streams collected events further, complete it and create a fresh new stream.
WindowShiftAction(Environment, Dispatcher, int, int) - Constructor for class reactor.rx.action.aggregation.WindowShiftAction
 
WindowShiftAction(Environment, Dispatcher, int, int, long, long, TimeUnit, Timer) - Constructor for class reactor.rx.action.aggregation.WindowShiftAction
 
WindowShiftWhenAction<T> - Class in reactor.rx.action.aggregation
WindowAction is forwarding events on a steam until is reached, after that streams collected events further, complete it and create a fresh new stream.
WindowShiftWhenAction(Environment, Dispatcher, Publisher<?>, Supplier<? extends Publisher<?>>) - Constructor for class reactor.rx.action.aggregation.WindowShiftWhenAction
 
WindowWhenAction<T> - Class in reactor.rx.action.aggregation
WindowAction is forwarding events on a steam until returned stream emits a signal, after that streams collected events further, complete it and create a fresh new stream.
WindowWhenAction(Environment, Dispatcher, Supplier<? extends Publisher<?>>) - Constructor for class reactor.rx.action.aggregation.WindowWhenAction
 
WIP_UPDATER - Static variable in class reactor.rx.action.combination.DynamicMergeAction
 
WORK_QUEUE - Static variable in class reactor.Environment
The name of the default work queue dispatcher
workDispatcher() - Static method in class reactor.Environment
Obtain a multi threaded dispatcher useful for scaling up slow processing.
WorkQueueDispatcher - Class in reactor.core.dispatch
Implementation of a Dispatcher that uses a multi-threaded, multi-producer RingBuffer to queue tasks to execute.
WorkQueueDispatcher(String, int, int, Consumer<Throwable>) - Constructor for class reactor.core.dispatch.WorkQueueDispatcher
 
WorkQueueDispatcher(String, int, int, Consumer<Throwable>, ProducerType, WaitStrategy) - Constructor for class reactor.core.dispatch.WorkQueueDispatcher
 
wrap(T) - Static method in class reactor.bus.Event
Wrap the given object with an Event.
wrap(T, Object) - Static method in class reactor.bus.Event
Wrap the given object with an Event and set the replyTo to the given replyToKey.
wrap(ExecutorService) - Static method in class reactor.core.processor.util.SingleUseExecutor
 
wrap(byte[]) - Static method in class reactor.io.buffer.Buffer
Convenience method to create a new, fixed-length Buffer and putting the given byte array into the buffer.
wrap(String, boolean) - Static method in class reactor.io.buffer.Buffer
Convenience method to create a new Buffer from the given String and optionally specify whether the new Buffer should be a fixed length or not.
wrap(String) - Static method in class reactor.io.buffer.Buffer
Convenience method to create a new, fixed-length Buffer from the given String.
wrap(Function<I, O>) - Method in class reactor.rx.stream.BarrierStream
 
wrap(Consumer<I>) - Method in class reactor.rx.stream.BarrierStream
 
wrap(Publisher<T>) - Static method in class reactor.rx.Streams
A simple decoration of the given Publisher to expose Stream API and proxy any subscribe call to the publisher.
wrap(Subscription, Subscriber<? super O>) - Static method in class reactor.rx.subscription.PushSubscription
Wrap the subscription behind a push subscription to start tracking its requests
WrappedSubscription<O> - Class in reactor.rx.subscription.support
 
WrappedSubscription(Subscription, Subscriber<? super O>) - Constructor for class reactor.rx.subscription.support.WrappedSubscription
 
WritableHeaders<T> - Interface in reactor.io.net.http.model
 
write(ByteBuffer) - Method in class reactor.io.buffer.Buffer
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class reactor.io.net.impl.netty.NettyChannelHandlerBridge
 
writeBufferWith(Publisher<? extends Buffer>) - Method in class reactor.io.net.ChannelStream
Write Buffer directly to be encoded if any codec has been setup
writeFirst(ChannelHandlerContext) - Method in class reactor.io.net.impl.netty.http.NettyHttpClientHandler
 
writeFirst(ChannelHandlerContext) - Method in class reactor.io.net.impl.netty.http.NettyHttpWSClientHandler
 
writeIdle(long, Consumer<Void>) - Method in interface reactor.io.net.ReactorChannel.ConsumerSpec
Assign a Runnable to be invoked when writes have become idle for the given timeout.
writeLast(ChannelHandlerContext) - Method in class reactor.io.net.impl.netty.http.NettyHttpClientHandler
 
writeLast(ChannelHandlerContext) - Method in class reactor.io.net.impl.netty.http.NettyHttpServerHandler
 
writeLast(ChannelHandlerContext) - Method in class reactor.io.net.impl.netty.http.NettyHttpWSClientHandler
 
writeLast(ChannelHandlerContext) - Method in class reactor.io.net.impl.netty.http.NettyHttpWSServerHandler
 
writePut(K, V, V) - Method in class reactor.rx.stream.io.ChronicleStream
 
writePutAll(Map<? extends K, ? extends V>) - Method in class reactor.rx.stream.io.ChronicleStream
 
writeRemove(Object) - Method in class reactor.rx.stream.io.ChronicleStream
 
writeWith(Publisher<? extends E>) - Method in class reactor.core.processor.RingBufferProcessor
 
writeWith(Publisher<? extends E>) - Method in class reactor.core.processor.RingBufferWorkProcessor
 
writeWith(Publisher<? extends E>, RingBuffer<MutableSignal<E>>) - Static method in class reactor.core.processor.util.RingBufferSubscriberUtils
 
writeWith(Publisher<? extends OUT>) - Method in class reactor.io.net.ChannelStream
 
writeWith(Publisher<? extends OUT>) - Method in interface reactor.io.net.ReactorChannel
Send data to the peer, listen for any error on write and close on terminal signal (complete|error).
ws(String) - Method in class reactor.io.net.http.HttpClient
WebSocket to the passed URL.
ws(String, ReactorChannelHandler<IN, OUT, HttpChannel<IN, OUT>>) - Method in class reactor.io.net.http.HttpClient
WebSocket to the passed URL.
ws(String, ReactorChannelHandler<IN, OUT, HttpChannel<IN, OUT>>) - Method in class reactor.io.net.http.HttpServer
Listen for WebSocket on the passed path to be used as a routing condition.
WS - Static variable in class reactor.io.net.http.model.Method
 
ws(String) - Static method in class reactor.io.net.NetSelectors
WS_SCHEME - Static variable in class reactor.io.net.http.HttpChannel
 
WSS_SCHEME - Static variable in class reactor.io.net.http.HttpChannel
 
WWW_AUTHENTICATE - Static variable in interface reactor.io.net.http.model.ResponseHeaders
The HTTP WWW-Authenticate header field name.

X

xor(Predicate<? super T>, Predicate<? super T>) - Static method in class reactor.fn.Predicates
Deprecated.
Returns a Predicate which evaluates to true if either both Predicate Predicates return true or neither of them do.

Y

YieldingWait() - Constructor for class reactor.fn.timer.HashWheelTimer.YieldingWait
 

Z

ZeroMQ<T> - Class in reactor.io.net.impl.zmq.tcp
 
ZeroMQ(Environment) - Constructor for class reactor.io.net.impl.zmq.tcp.ZeroMQ
 
ZeroMQ(Environment, String) - Constructor for class reactor.io.net.impl.zmq.tcp.ZeroMQ
 
ZeroMQ(Environment, Dispatcher) - Constructor for class reactor.io.net.impl.zmq.tcp.ZeroMQ
 
ZeroMQChannelStream<IN,OUT> - Class in reactor.io.net.impl.zmq
 
ZeroMQChannelStream(Environment, long, Dispatcher, InetSocketAddress, Codec<Buffer, IN, OUT>) - Constructor for class reactor.io.net.impl.zmq.ZeroMQChannelStream
 
ZeroMQClientSocketOptions - Class in reactor.io.net.impl.zmq
ClientSocketOptions that include ZeroMQ-specific configuration options.
ZeroMQClientSocketOptions() - Constructor for class reactor.io.net.impl.zmq.ZeroMQClientSocketOptions
 
ZeroMQServerSocketOptions - Class in reactor.io.net.impl.zmq
ServerSocketOptions that include ZeroMQ-specific configuration options.
ZeroMQServerSocketOptions() - Constructor for class reactor.io.net.impl.zmq.ZeroMQServerSocketOptions
 
ZeroMQTcpClient<IN,OUT> - Class in reactor.io.net.impl.zmq.tcp
 
ZeroMQTcpClient(Environment, Dispatcher, Supplier<InetSocketAddress>, ClientSocketOptions, SslOptions, Codec<Buffer, IN, OUT>) - Constructor for class reactor.io.net.impl.zmq.tcp.ZeroMQTcpClient
 
ZeroMQTcpServer<IN,OUT> - Class in reactor.io.net.impl.zmq.tcp
 
ZeroMQTcpServer(Environment, Dispatcher, InetSocketAddress, ServerSocketOptions, SslOptions, Codec<Buffer, IN, OUT>) - Constructor for class reactor.io.net.impl.zmq.tcp.ZeroMQTcpServer
 
ZeroMQWorker - Class in reactor.io.net.impl.zmq
 
ZeroMQWorker(UUID, int, int, ZContext, Broadcaster<ZMsg>) - Constructor for class reactor.io.net.impl.zmq.ZeroMQWorker
 
zip(Function<TupleN, ? extends V>) - Method in class reactor.rx.Stream
Stream.lift(Supplier) all the nested Publisher values to a new Stream until one of them complete.
zip(Publisher<? extends T1>, Publisher<? extends T2>, Function<Tuple2<T1, T2>, ? extends V>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the passed publishers.
zip(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Function<Tuple3<T1, T2, T3>, ? extends V>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the passed publishers.
zip(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Function<Tuple4<T1, T2, T3, T4>, V>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the passed publishers.
zip(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Function<Tuple5<T1, T2, T3, T4, T5>, V>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the passed publishers.
zip(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Publisher<? extends T6>, Function<Tuple6<T1, T2, T3, T4, T5, T6>, V>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the passed publishers.
zip(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Publisher<? extends T6>, Publisher<? extends T7>, Function<Tuple7<T1, T2, T3, T4, T5, T6, T7>, V>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the passed publishers.
zip(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Publisher<? extends T6>, Publisher<? extends T7>, Publisher<? extends T8>, Function<Tuple8<T1, T2, T3, T4, T5, T6, T7, T8>, ? extends V>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the passed publishers.
zip(List<? extends Publisher<?>>, Function<TUPLE, ? extends V>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the passed publishers.
zip(Publisher<? extends Publisher<E>>, Function<TUPLE, ? extends V>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the passed publishers.
ZipAction<O,V,TUPLE extends Tuple> - Class in reactor.rx.action.combination
 
ZipAction(Dispatcher, Function<TUPLE, ? extends V>, List<? extends Publisher<? extends O>>) - Constructor for class reactor.rx.action.combination.ZipAction
 
ZipAction.InnerSubscriber<O,V> - Class in reactor.rx.action.combination
 
ZipAction.Zippable<O> - Class in reactor.rx.action.combination
 
Zippable(int, O) - Constructor for class reactor.rx.action.combination.CombineLatestAction.Zippable
 
Zippable(int, O) - Constructor for class reactor.rx.action.combination.ZipAction.Zippable
 
zipWith(Iterable<? extends T2>, Function<Tuple2<O, T2>, V>) - Method in class reactor.rx.Stream
Stream.lift(Supplier) all the nested Publisher values to a new Stream until one of them complete.
zipWith(Publisher<? extends T2>, Function<Tuple2<O, T2>, V>) - Method in class reactor.rx.Stream
Stream.lift(Supplier) with the passed Publisher values to a new Stream until one of them complete.
$ A B C D E F G H I J K L M N O P Q R S T U V W X Y Z 
Skip navigation links
Reactor JavaDocs

Copyright © 2017. All rights reserved.