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

A

AbstractPushableStream<T,X extends Adapter<T>,R extends java.util.stream.Stream<T>> - Class in com.aol.simple.react.stream.pushable
 
AbstractPushableStream(X, R) - Constructor for class com.aol.simple.react.stream.pushable.AbstractPushableStream
 
accept(FastFuture<T>) - Method in class com.aol.simple.react.collectors.lazy.BatchingCollector
 
accept(FastFuture<T>) - Method in class com.aol.simple.react.collectors.lazy.EmptyCollector
 
accept(FastFuture<T>) - Method in class com.aol.simple.react.collectors.lazy.SamplingCollector
 
actOnFutures() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
LazyFutureStream operators act on the results of the previous stage by default.
Adapter<T> - Interface in com.aol.simple.react.async
Interface for an Adapter that inputs data from 1 or more input Streams and sends it to 1 or more output Streams
add(Object) - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
add(T) - Method in class com.aol.simple.react.async.Queue
Add a single data point to the queue If the queue is a bounded queue and is full, will return false
add(FastFuture<T>) - Method in class com.aol.simple.react.collectors.lazy.EmptyCollector
 
add(U, Queue<U>) - Method in interface com.aol.simple.react.stream.traits.LazyToQueue
 
addAll(Collection) - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
addContinuation(Continuation) - Method in interface com.aol.simple.react.async.ContinuationStrategy
 
addContinuation(Continuation) - Method in class com.aol.simple.react.async.Queue
 
addContinuation(Continuation) - Method in class com.aol.simple.react.async.SingleContinuation
 
addContinuation(Continuation) - Method in class com.aol.simple.react.async.StreamOfContinuations
 
addQueue(Queue) - Method in class com.aol.simple.react.async.subscription.AlwaysContinue
 
addQueue(Queue) - Method in interface com.aol.simple.react.async.subscription.Continueable
 
addQueue(Queue) - Method in class com.aol.simple.react.async.subscription.Subscription
 
addToQueue(Queue) - Method in interface com.aol.simple.react.stream.traits.EagerToQueue
 
addToQueue(Queue) - Method in interface com.aol.simple.react.stream.traits.LazyToQueue
 
addToQueue(Queue) - Method in interface com.aol.simple.react.stream.traits.ToQueue
 
allMatch(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
allOf(Runnable, FastFuture...) - Static method in class com.aol.simple.react.async.future.FastFuture
 
allOf(Collector, Function<T, R>) - Method in class com.aol.simple.react.stream.simple.SimpleReactStreamImpl
 
allOf(Collector, Function<T, R>) - Method in interface com.aol.simple.react.stream.traits.EagerToQueue
 
allOf(Collector, Function<T, R>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
allOf(Function<List<T>, R>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
React and allOf allOf is a non-blocking equivalent of block.
AlwaysContinue - Class in com.aol.simple.react.async.subscription
 
AlwaysContinue() - Constructor for class com.aol.simple.react.async.subscription.AlwaysContinue
 
anyM() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
anyMatch(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
anyOf(FastFuture...) - Static method in class com.aol.simple.react.async.future.FastFuture
 
anyOf(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
React to the completion of any of the events in the previous stage.
append(T...) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Append values to the end of this SequenceM
append(U...) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
appendFutures(CompletableFuture<T>...) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Append the provided Futures to this Stream
appendStream(Stream<T>) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Append Stream to this Stream
appendStream(Stream<U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
appendStreamFutures(Stream<CompletableFuture<T>>) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Append a Stream of Futures to this Stream
apply(Supplier<U>) - Method in class com.aol.simple.react.stream.traits.operators.BatchBySize
 
apply(BiFunction<Long, TimeUnit, U>) - Method in class com.aol.simple.react.stream.traits.operators.BatchByTime
 
apply(BiFunction<Long, TimeUnit, U>) - Method in class com.aol.simple.react.stream.traits.operators.BatchByTimeAndSize
 
apply(Supplier<T>) - Method in class com.aol.simple.react.stream.traits.operators.Debounce
 
apply(Supplier<U>) - Method in class com.aol.simple.react.stream.traits.operators.OnePer
 
assureSimpleReactException(Throwable) - Static method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
 
assureSimpleReactException(Throwable) - Static method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
async(Function<LazyReact, LazyFutureStream<T>>) - Method in interface com.aol.simple.react.mixins.LazyReactive
Generate a multi-threaded LazyFutureStream that executes all tasks via a task executor between each stage (unless sync operator invoked).
async() - Method in class com.aol.simple.react.stream.lazy.LazyReact
Start any created Streams in asyncrhonous mode - that is tasks will be submited to an Executor to be run.
async() - Method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
 
async() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
async() - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
autoMemoizeOn(Cacheable) - Method in class com.aol.simple.react.stream.lazy.LazyReact
 
autoOptimizeOff() - Method in class com.aol.simple.react.stream.lazy.LazyReact
Turn off automatic threading management.
autoOptimizeOn() - Method in class com.aol.simple.react.stream.lazy.LazyReact
Turn on automatic threading optimization.
await() - Method in class com.aol.simple.react.async.future.FastFuture
 

B

BaseSimpleReact - Class in com.aol.simple.react.stream
 
BaseSimpleReact() - Constructor for class com.aol.simple.react.stream.BaseSimpleReact
 
BaseSimpleReact(Executor) - Constructor for class com.aol.simple.react.stream.BaseSimpleReact
 
BaseSimpleReactStream<U> - Interface in com.aol.simple.react.stream.traits
 
batch(Function<Supplier<U>, Supplier<C>>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Batch elements into a Stream of collections with user defined function
batchBySize(int) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Batch the elements in this stream into Lists of specified size
batchBySize(int, Supplier<C>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Batch the elements in this stream into Collections of specified size The type of Collection is determined by the specified supplier
BatchBySize<U,C extends java.util.Collection<U>> - Class in com.aol.simple.react.stream.traits.operators
 
BatchBySize() - Constructor for class com.aol.simple.react.stream.traits.operators.BatchBySize
 
batchBySizeAndTime(int, long, TimeUnit) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
batchBySizeAndTime(int, long, TimeUnit, Supplier<C>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
batchByTime(long, TimeUnit) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Organise elements in a Stream into a Collections based on the time period they pass through this stage
batchByTime(long, TimeUnit, Supplier<C>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Organise elements in a Stream into a Collections based on the time period they pass through this stage
BatchByTime<U> - Class in com.aol.simple.react.stream.traits.operators
 
BatchByTime() - Constructor for class com.aol.simple.react.stream.traits.operators.BatchByTime
 
BatchByTimeAndSize<U> - Class in com.aol.simple.react.stream.traits.operators
 
BatchByTimeAndSize() - Constructor for class com.aol.simple.react.stream.traits.operators.BatchByTimeAndSize
 
BatchingCollector<T> - Class in com.aol.simple.react.collectors.lazy
This class allows a Batch of completable futures to be processed before collecting their results, to increase parallelism.
BatchingCollector(MaxActive, BlockingStream<T>) - Constructor for class com.aol.simple.react.collectors.lazy.BatchingCollector
 
batchUntil(Predicate<U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
batchUntil(Predicate<U>, Supplier<C>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
batchWhile(Predicate<U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
batchWhile(Predicate<U>, Supplier<C>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
bind(SimpleReactStream<U>, Function<U, BaseSimpleReactStream<R>>) - Static method in interface com.aol.simple.react.stream.traits.SimpleReactStream
flatMap / bind implementation that returns the correct type (SimpleReactStream)
block(Predicate<Status>) - Method in class com.aol.simple.react.blockers.Blocker
 
block(Function<FastFuture<T>, T>) - Method in class com.aol.simple.react.collectors.lazy.BatchingCollector
 
block(Function<FastFuture<T>, T>) - Method in class com.aol.simple.react.collectors.lazy.EmptyCollector
 
block(Function<FastFuture<T>, T>) - Method in interface com.aol.simple.react.collectors.lazy.LazyResultConsumer
 
block(Function<FastFuture<T>, T>) - Method in class com.aol.simple.react.collectors.lazy.SamplingCollector
 
block() - Method in interface com.aol.simple.react.stream.traits.BlockingStream
React and block
block(Collector<? super U, A, R>) - Method in interface com.aol.simple.react.stream.traits.BlockingStream
 
block(Predicate<Status>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
React and block with breakout Sometimes you may not need to block until all the work is complete, one result or a subset may be enough.
block(Collector, Predicate<Status>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
blockAndExtract(Extractor) - Method in interface com.aol.simple.react.stream.traits.BlockingStream
Block until tasks complete and return a value determined by the extractor supplied.
blockAndExtract(Extractor, Predicate<Status>) - Method in interface com.aol.simple.react.stream.traits.BlockingStream
Block until tasks complete, or breakout conditions met and return a value determined by the extractor supplied.
Blocker<U> - Class in com.aol.simple.react.blockers
 
Blocker() - Constructor for class com.aol.simple.react.blockers.Blocker
 
BlockingStream<U> - Interface in com.aol.simple.react.stream.traits
 
BlockingStreamHelper - Class in com.aol.simple.react.stream.traits
 
BlockingStreamHelper() - Constructor for class com.aol.simple.react.stream.traits.BlockingStreamHelper
 
boundedNonBlockingQueue(int) - Static method in class com.aol.simple.react.async.factories.QueueFactories
Creates an async.Queue backed by an Agrona ManyToOneConcurrentArrayQueue bounded by specified queueSize Wait strategy used is NoWaitRetry by default for both Consumers and Producers (both Consumers and Producers will repeatedly retry until successful).
boundedPool(Collection<REACTOR>) - Static method in class com.aol.simple.react.threads.ReactPool
If all REACTORs are in use calling react will block.
boundedQueue(int) - Static method in class com.aol.simple.react.async.factories.QueueFactories
 
boundedWaitFree(int) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Use an Agrona ManyToOneConcurrentArrayQueue for the next operations (wait-free, mechanical sympathy).
build() - Method in interface com.aol.simple.react.async.factories.QueueFactory
 
build() - Method in class com.aol.simple.react.async.future.PipelineBuilder
 

C

cancel() - Method in interface com.aol.simple.react.reactivestreams.FutureStreamAsyncPublisher
 
cancel() - Method in interface com.aol.simple.react.reactivestreams.FutureStreamSynchronousPublisher
 
cancel() - Method in class com.aol.simple.react.stream.lazy.LazyFutureStreamImpl
Cancel the CompletableFutures in this stage of the stream
cancel() - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Cancel the CompletableFutures in this stage of the stream
capture(Consumer<? extends Throwable>) - Method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
React capture While onFail is used for disaster recovery (when it is possible to recover) - capture is used to capture those occasions where the full pipeline has failed and is unrecoverable.
capture(Consumer<? extends Throwable>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
capture(Consumer<? extends Throwable>) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
React capture While onFail is used for disaster recovery (when it is possible to recover) - capture is used to capture those occasions where the full pipeline has failed and is unrecoverable.
capture(Consumer<? extends Throwable>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
React capture While onFail is used for disaster recovery (when it is possible to recover) - capture is used to capture those occasions where the full pipeline has failed and is unrecoverable.
cast(Class<U>) - Method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
 
cast(Class<U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
characteristics() - Method in class com.aol.simple.react.async.ClosingSpliterator
 
characteristics() - Method in class com.aol.simple.react.stream.InfiniteClosingSpliterator
 
characteristics() - Method in class com.aol.simple.react.stream.InfiniteClosingSpliteratorFromIterator
 
chunkLastReadIterator() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
chunkSinceLastRead() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
clear() - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
clear() - Static method in class com.aol.simple.react.async.pipes.Pipes
 
clearFast() - Method in class com.aol.simple.react.async.future.FastFuture
 
close() - Method in interface com.aol.simple.react.async.Adapter
Close this adapter
close() - Method in class com.aol.simple.react.async.Queue
Close this Queue
close() - Method in class com.aol.simple.react.async.Signal
Close this Signal
close() - Method in class com.aol.simple.react.async.Topic
Close this Topic
close() - Method in class com.aol.simple.react.stream.CloseableIterator
 
close() - Method in class com.aol.simple.react.stream.lazy.LazyFutureStreamImpl
 
CloseableIterator<T> - Class in com.aol.simple.react.stream
 
CloseableIterator() - Constructor for class com.aol.simple.react.stream.CloseableIterator
 
closeAll(Queue) - Method in class com.aol.simple.react.async.subscription.AlwaysContinue
 
closeAll() - Method in class com.aol.simple.react.async.subscription.AlwaysContinue
 
closeAll(Queue) - Method in interface com.aol.simple.react.async.subscription.Continueable
 
closeAll() - Method in interface com.aol.simple.react.async.subscription.Continueable
 
closeAll(Queue) - Method in class com.aol.simple.react.async.subscription.Subscription
 
closeAll() - Method in class com.aol.simple.react.async.subscription.Subscription
 
closeAll() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
closes all open queues.
closeAndClear() - Method in class com.aol.simple.react.async.Queue
 
closed() - Method in class com.aol.simple.react.async.subscription.AlwaysContinue
 
closed() - Method in interface com.aol.simple.react.async.subscription.Continueable
 
closed() - Method in class com.aol.simple.react.async.subscription.Subscription
 
ClosedQueueException() - Constructor for exception com.aol.simple.react.async.Queue.ClosedQueueException
 
closeQueueIfFinished(Queue) - Method in class com.aol.simple.react.async.subscription.AlwaysContinue
 
closeQueueIfFinished(Queue) - Method in interface com.aol.simple.react.async.subscription.Continueable
 
closeQueueIfFinished(Queue) - Method in class com.aol.simple.react.async.subscription.Subscription
 
closeQueueIfFinishedStateless(Queue) - Method in class com.aol.simple.react.async.subscription.AlwaysContinue
 
closeQueueIfFinishedStateless(Queue) - Method in interface com.aol.simple.react.async.subscription.Continueable
 
closeQueueIfFinishedStateless(Queue) - Method in class com.aol.simple.react.async.subscription.Subscription
 
ClosingSpliterator<T> - Class in com.aol.simple.react.async
 
ClosingSpliterator(long, Supplier<T>, Continueable, Queue) - Constructor for class com.aol.simple.react.async.ClosingSpliterator
 
ClosingSpliterator(long, Supplier<T>, Continueable) - Constructor for class com.aol.simple.react.async.ClosingSpliterator
 
collect(Collector<? super U, A, R>) - Method in class com.aol.simple.react.stream.lazy.LazyFutureStreamImpl
 
collect(Collector<? super CompletableFuture<T>, A, R>) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Collect a Stream
collect(Supplier<R>, BiConsumer<R, ? super U>, BiConsumer<R, R>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
collect(Supplier<R>, BiConsumer<R, ? super U>, BiConsumer<R, R>) - Method in interface com.aol.simple.react.stream.traits.LazyStream
 
collectIterable(Iterable<Collector>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
collectStream(Stream<Collector>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
com.aol.simple.react - package com.aol.simple.react
 
com.aol.simple.react.async - package com.aol.simple.react.async
 
com.aol.simple.react.async.factories - package com.aol.simple.react.async.factories
 
com.aol.simple.react.async.future - package com.aol.simple.react.async.future
 
com.aol.simple.react.async.future.pool - package com.aol.simple.react.async.future.pool
 
com.aol.simple.react.async.pipes - package com.aol.simple.react.async.pipes
 
com.aol.simple.react.async.subscription - package com.aol.simple.react.async.subscription
 
com.aol.simple.react.async.wait - package com.aol.simple.react.async.wait
 
com.aol.simple.react.blockers - package com.aol.simple.react.blockers
 
com.aol.simple.react.collectors.lazy - package com.aol.simple.react.collectors.lazy
 
com.aol.simple.react.config - package com.aol.simple.react.config
 
com.aol.simple.react.exceptions - package com.aol.simple.react.exceptions
 
com.aol.simple.react.extractors - package com.aol.simple.react.extractors
 
com.aol.simple.react.mixins - package com.aol.simple.react.mixins
 
com.aol.simple.react.monad - package com.aol.simple.react.monad
 
com.aol.simple.react.reactivestreams - package com.aol.simple.react.reactivestreams
 
com.aol.simple.react.reactivestreams.sequenceM - package com.aol.simple.react.reactivestreams.sequenceM
 
com.aol.simple.react.stream - package com.aol.simple.react.stream
 
com.aol.simple.react.stream.lazy - package com.aol.simple.react.stream.lazy
 
com.aol.simple.react.stream.pushable - package com.aol.simple.react.stream.pushable
 
com.aol.simple.react.stream.simple - package com.aol.simple.react.stream.simple
 
com.aol.simple.react.stream.traits - package com.aol.simple.react.stream.traits
 
com.aol.simple.react.stream.traits.future.operators - package com.aol.simple.react.stream.traits.future.operators
 
com.aol.simple.react.stream.traits.operators - package com.aol.simple.react.stream.traits.operators
 
com.aol.simple.react.threads - package com.aol.simple.react.threads
 
com.aol.simple.react.util - package com.aol.simple.react.util
 
combineLatest(SimpleReactStream<T2>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
CompletedException - Exception in com.aol.simple.react.async.future
 
CompletedException(Object) - Constructor for exception com.aol.simple.react.async.future.CompletedException
 
completedFuture(T) - Static method in class com.aol.simple.react.async.future.FastFuture
 
concat(Stream<U>) - Method in class com.aol.simple.react.stream.LazyStreamWrapper
 
concat(Stream<T>) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
 
concat(T) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
 
concat(T...) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
 
concat(Stream<U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Concatenate two streams.
concat(U) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Concatenate two streams.
concat(U...) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Concatenate two streams.
concatFutures(CompletableFuture<T>...) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Concat supplied Futures to this Stream
concatStreamFutures(Stream<CompletableFuture<T>>) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Concat supplied Futures to this Stream
ConfigurableStream<T,C> - Interface in com.aol.simple.react.stream.traits
 
construct(Stream) - Method in class com.aol.simple.react.stream.BaseSimpleReact
 
construct(Stream) - Method in class com.aol.simple.react.stream.lazy.LazyReact
 
construct(Stream) - Method in class com.aol.simple.react.stream.simple.SimpleReact
 
constructFutures(Stream<CompletableFuture<U>>) - Method in class com.aol.simple.react.stream.lazy.LazyReact
 
contains(Object) - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
containsAll(Collection) - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
Continuation - Class in com.aol.simple.react.stream.traits
 
Continuation() - Constructor for class com.aol.simple.react.stream.traits.Continuation
 
ContinuationStrategy - Interface in com.aol.simple.react.async
 
Continueable - Interface in com.aol.simple.react.async.subscription
 
control(Function<Supplier<U>, Supplier<U>>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Allows clients to control the emission of data for the next phase of the Stream.
convertToLazyStream() - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Convert between an Lazy and Eager future stream, can be used to take advantages of each approach during a single Stream
convertToSimpleReact() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Convert between an Lazy and Eager SimpleReact Stream, can be used to take advantages of each approach during a single Stream Allows callers to take advantage of functionality only available in SimpleReactStreams such as allOf
copy(int) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Copy this Stream the specified number of times
copySimpleReactStream(int) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
 
copySimpleReactStream(int) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
count() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
CPU - Static variable in class com.aol.simple.react.config.MaxActive
 
cpuReact - Static variable in class com.aol.simple.react.async.pipes.EagerReactors
 
cpuReact - Static variable in class com.aol.simple.react.async.pipes.LazyReactors
 
cpuStream() - Method in interface com.aol.simple.react.mixins.LazyReactive
 
createMergeQueue() - Static method in class com.aol.simple.react.async.Queue
 
crossJoin(Stream<T>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Cross join 2 streams into one.
cycle(int) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Convert to a Stream with the values repeated specified times
cycle() - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Convert to a Stream with the values infinitely cycled
cycle() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Create a Stream that infinitely cycles this Stream
cycle(int) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Create a Stream that finitely cycles this Stream, provided number of times
cycle(Monoid<U>, int) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
cycle(Class<R>, int) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
cycleUntil(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Repeat in a Stream until specified predicate holds
cycleWhile(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Repeat in a Stream while specified predicate holds

D

debounce(long, TimeUnit) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Can be used to debounce (accept a single data point from a unit of time) data.
Debounce<T> - Class in com.aol.simple.react.stream.traits.operators
 
Debounce() - Constructor for class com.aol.simple.react.stream.traits.operators.Debounce
 
defaultValue - Static variable in class com.aol.simple.react.stream.lazy.ParallelReductionConfig
 
deleteBetween(int, int) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Delete elements between given indexes in a Stream
deleteBetween(int, int) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
DirectWaitStrategy<T> - Class in com.aol.simple.react.async.wait
Will try to access the queue once, and return the result directly from the Queue Effectively the same as calling queue.take() / queue.offer(T val)
DirectWaitStrategy() - Constructor for class com.aol.simple.react.async.wait.DirectWaitStrategy
 
disconnect(Stream<T>) - Method in class com.aol.simple.react.async.Topic
Topic will maintain a queue for each Subscribing Stream If a Stream is finished with a Topic it is good practice to disconnect from the Topic so messages will no longer be stored for that Stream
distinct() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
distinct(Function<? super U, ? extends R>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
done(FastFuture<T>) - Method in class com.aol.simple.react.async.future.pool.FuturePool
 
doOnEach(Function<U, U>) - Method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
Applies a function to this phase independent on the main flow.
doOnEach(Function<U, U>) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
Applies a function to this phase independent on the main flow.
doOnEach(Function<U, U>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Applies a function to this phase independent on the main flow.
doOnEachSync(Function<U, U>) - Method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
Applies a function to this phase independent on the main flow, continues on the currently executing thread.
doOnEachSync(Function<U, U>) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
Applies a function to this phase independent on the main flow, continues on the currently executing thread.
doOnEachSync(Function<U, U>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Applies a function to this phase independent on the main flow, continues on the currently executing thread.
drainTo(Collection) - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
drainTo(Collection, int) - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
drainToOrBlock() - Method in class com.aol.simple.react.async.Queue.QueueReader
 
duplicate() - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Duplicate a Stream, buffers intermediate values, leaders may change positions so a limit can be safely applied to the leading stream.
duplicate() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Duplicate a LazyFutureStream into two equivalent Streams.
duplicate() - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Duplicate a Stream into two equivalent LazyFutureStreams, underlying Stream of Futures is duplicated
duplicateFutureStream() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
duplicateSequence() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 

E

EagerFutureStreamFunctions - Class in com.aol.simple.react.stream.traits
 
EagerFutureStreamFunctions() - Constructor for class com.aol.simple.react.stream.traits.EagerFutureStreamFunctions
 
EagerReactors - Class in com.aol.simple.react.async.pipes
 
EagerReactors() - Constructor for class com.aol.simple.react.async.pipes.EagerReactors
 
EagerStreamWrapper - Class in com.aol.simple.react.stream
 
EagerStreamWrapper(List<CompletableFuture>) - Constructor for class com.aol.simple.react.stream.EagerStreamWrapper
 
EagerStreamWrapper(EagerStreamWrapper.AsyncList) - Constructor for class com.aol.simple.react.stream.EagerStreamWrapper
 
EagerStreamWrapper(Stream<CompletableFuture>) - Constructor for class com.aol.simple.react.stream.EagerStreamWrapper
 
EagerStreamWrapper(Stream<CompletableFuture>, Collector) - Constructor for class com.aol.simple.react.stream.EagerStreamWrapper
 
EagerStreamWrapper(CompletableFuture) - Constructor for class com.aol.simple.react.stream.EagerStreamWrapper
 
EagerToQueue<U> - Interface in com.aol.simple.react.stream.traits
 
elasticPool(Supplier<REACTOR>) - Static method in class com.aol.simple.react.threads.ReactPool
If all REACTORs are in use calling react will create a new REACTOR to handle the extra demand.
element() - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
elementAt(long) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Return the elementAt index or Optional.empty
empty() - Static method in class com.aol.simple.react.async.future.ExecutionPipeline
 
empty() - Static method in class com.aol.simple.react.async.future.FinalPipeline
 
empty() - Method in class com.aol.simple.react.monad.LazyFutureStreamComprehender
 
empty() - Method in class com.aol.simple.react.monad.SimpleReactStreamComprehender
 
empty() - Static method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
Create an empty sequential synchronous stream that runs on the current thread
empty() - Static method in class com.aol.simple.react.stream.traits.Continuation
 
empty() - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Create a sequential synchronous stream that runs on the current thread
EmptyCollector<T> - Class in com.aol.simple.react.collectors.lazy
A collector that periodically joins active completablefutures but does not store the results
endsWith(Iterable<U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
endsWith(Stream<U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
enqueue(K, V) - Method in interface com.aol.simple.react.mixins.LazyReactive
Add a value to an simple-react Async.Adapter (Queue / Topic /Signal) if present Returns the Adapter wrapped in an Optional
equals(Object) - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
essential(Consumer<FastFuture.OnComplete>) - Method in class com.aol.simple.react.async.future.FastFuture
Called at least once on complete
estimateSize() - Method in class com.aol.simple.react.async.ClosingSpliterator
 
estimateSize() - Method in class com.aol.simple.react.stream.InfiniteClosingSpliterator
 
estimateSize() - Method in class com.aol.simple.react.stream.InfiniteClosingSpliteratorFromIterator
 
exception - Variable in class com.aol.simple.react.async.future.FastFuture.OnComplete
 
exceptionally(Function<X, T>) - Method in class com.aol.simple.react.async.future.ExecutionPipeline
 
exceptionally - Variable in class com.aol.simple.react.async.future.FastFuture.OnComplete
 
exceptionally(Function<X, T>) - Method in class com.aol.simple.react.async.future.PipelineBuilder
 
ExceptionSoftener - Class in com.aol.simple.react.exceptions
 
ExceptionSoftener() - Constructor for class com.aol.simple.react.exceptions.ExceptionSoftener
 
ExceptionSoftener.singleton - Enum in com.aol.simple.react.exceptions
 
ExecutionPipeline - Class in com.aol.simple.react.async.future
 
ExecutionPipeline() - Constructor for class com.aol.simple.react.async.future.ExecutionPipeline
 
executors - Variable in class com.aol.simple.react.async.future.FinalPipeline
 
ExponentialBackofWaitStrategy<T> - Class in com.aol.simple.react.async.wait
 
ExponentialBackofWaitStrategy() - Constructor for class com.aol.simple.react.async.wait.ExponentialBackofWaitStrategy
 
extract(T) - Method in interface com.aol.simple.react.extractors.Extractor
 
Extractor<T,R> - Interface in com.aol.simple.react.extractors
Functional interface for extracting results from a blocking call.
Extractors - Class in com.aol.simple.react.extractors
Default extractors for determining return values from blocking stage.
Extractors() - Constructor for class com.aol.simple.react.extractors.Extractors
 

F

failedFuture(Throwable) - Static method in class com.aol.simple.react.async.future.FastFuture
 
FastFuture<T> - Class in com.aol.simple.react.async.future
 
FastFuture() - Constructor for class com.aol.simple.react.async.future.FastFuture
 
FastFuture(FinalPipeline, Consumer<FastFuture<T>>) - Constructor for class com.aol.simple.react.async.future.FastFuture
 
FastFuture(FinalPipeline, int) - Constructor for class com.aol.simple.react.async.future.FastFuture
 
FastFuture.OnComplete - Class in com.aol.simple.react.async.future
 
fillInStackTrace() - Method in exception com.aol.simple.react.async.future.CompletedException
 
fillInStackTrace() - Method in exception com.aol.simple.react.async.Queue.ClosedQueueException
 
fillInStackTrace() - Method in exception com.aol.simple.react.async.Queue.QueueTimeoutException
 
fillInStackTrace() - Method in exception com.aol.simple.react.exceptions.FilteredExecutionPathException
 
fillInStackTrace() - Method in exception com.aol.simple.react.exceptions.SimpleReactCompletionException
 
fillInStackTrace() - Method in exception com.aol.simple.react.exceptions.SimpleReactProcessingException
 
filter(LazyFutureStream, Predicate) - Method in class com.aol.simple.react.monad.LazyFutureStreamComprehender
 
filter(SimpleReactStream, Predicate) - Method in class com.aol.simple.react.monad.SimpleReactStreamComprehender
 
filter(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
Removes elements that do not match the supplied predicate from the dataflow
filter(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
filter(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
Removes elements that do not match the supplied predicate from the dataflow
filter(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Removes elements that do not match the supplied predicate from the dataflow
FilteredExecutionPathException - Exception in com.aol.simple.react.exceptions
 
FilteredExecutionPathException() - Constructor for exception com.aol.simple.react.exceptions.FilteredExecutionPathException
 
filterSync(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
Synchronous filtering operation Removes elements that do not match the supplied predicate from the dataflow
filterSync(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
Synchronous filtering operation Removes elements that do not match the supplied predicate from the dataflow
filterSync(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Synchronous filtering operation Removes elements that do not match the supplied predicate from the dataflow
FinalPipeline - Class in com.aol.simple.react.async.future
 
FinalPipeline() - Constructor for class com.aol.simple.react.async.future.FinalPipeline
 
findAny() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
findFirst() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
first() - Static method in class com.aol.simple.react.extractors.Extractors
 
first() - Method in interface com.aol.simple.react.stream.traits.BlockingStream
Block until first result received
firstOf(SimpleReactStream<U>...) - Static method in class com.aol.simple.react.stream.traits.EagerFutureStreamFunctions
Return first Stream out of provided Streams that starts emitted results
firstOf(SimpleReactStream<U>...) - Static method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Return first Stream out of provided Streams that starts emitted results
firstRecover - Variable in class com.aol.simple.react.async.future.FinalPipeline
 
firstValue() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
fixedDelay(long, TimeUnit) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Apply a fixed delay before emitting elements to the next phase of the Stream.
flatMap(LazyFutureStream, Function) - Method in class com.aol.simple.react.monad.LazyFutureStreamComprehender
 
flatMap(SimpleReactStream, Function) - Method in class com.aol.simple.react.monad.SimpleReactStreamComprehender
 
flatMap(Function<? super U, ? extends Stream<? extends R>>) - Method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
Allows aggregate values in a Stream to be flatten into a single Stream.
flatMap(Function<? super U, ? extends Stream<? extends R>>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
flatMap(Function<? super U, ? extends Stream<? extends R>>) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
Allows aggregate values in a Stream to be flatten into a single Stream.
flatMap(Function<? super U, ? extends Stream<? extends R>>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Allows aggregate values in a Stream to be flatten into a single Stream.
flatMapAnyM(Function<? super U, AnyM<? extends R>>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
flatMapBufferedReader(Function<? super U, BufferedReader>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
flatMapCharSequence(Function<? super U, CharSequence>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
flatMapCollection(Function<? super U, Collection<? extends R>>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
flatMapCompletableFuture(Function<? super U, CompletableFuture<? extends R>>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Perform a flatMap operation where the CompletableFuture type returned is flattened from the resulting Stream If in async mode this operation is performed asyncrhonously If in sync mode this operation is performed synchronously
flatMapFile(Function<? super U, File>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
flatMapOptional(Function<? super U, Optional<? extends R>>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
flatMapStream(Function<? super U, BaseStream<? extends R, ?>>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
flatMapToCompletableFuture(Function<U, CompletableFuture<R>>) - Method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
Perform a flatMap operation where the CompletableFuture type returned is flattened from the resulting Stream If in async mode this operation is performed asyncrhonously If in sync mode this operation is performed synchronously
flatMapToCompletableFuture(Function<U, CompletableFuture<R>>) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
Perform a flatMap operation where the CompletableFuture type returned is flattened from the resulting Stream If in async mode this operation is performed asyncrhonously If in sync mode this operation is performed synchronously
flatMapToCompletableFuture(Function<U, CompletableFuture<R>>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Perform a flatMap operation where the CompletableFuture type returned is flattened from the resulting Stream If in async mode this operation is performed asyncrhonously If in sync mode this operation is performed synchronously
flatMapToCompletableFutureSync(Function<U, CompletableFuture<R>>) - Method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
Perform a flatMap operation where the CompletableFuture type returned is flattened from the resulting Stream This operation is performed synchronously
flatMapToCompletableFutureSync(Function<U, CompletableFuture<R>>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Perform a flatMap operation where the CompletableFuture type returned is flattened from the resulting Stream This operation is performed synchronously
flatMapToCompletableFutureSync(Function<U, CompletableFuture<R>>) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
Perform a flatMap operation where the CompletableFuture type returned is flattened from the resulting Stream This operation is performed synchronously
flatMapToCompletableFutureSync(Function<U, CompletableFuture<R>>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Perform a flatMap operation where the CompletableFuture type returned is flattened from the resulting Stream This operation is performed synchronously
flatMapToDouble(Function<? super U, ? extends DoubleStream>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
flatMapToInt(Function<? super U, ? extends IntStream>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
flatMapToLong(Function<? super U, ? extends LongStream>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
flatMapURL(Function<? super U, URL>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
flatten() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
foldLeft(CompletableFuture<T>, BinaryOperator<CompletableFuture<T>>) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Sequentially reduce from the left
foldLeft(U, BinaryOperator<U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
foldLeft(Monoid<U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
foldLeftMapToType(Monoid<T>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
foldRight(CompletableFuture<T>, BinaryOperator<CompletableFuture<T>>) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Reduce sequentially from the right
foldRight(U, BinaryOperator<U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
foldRight(Monoid<U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
foldRightMapToType(Monoid<T>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
forEach(Consumer) - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
forEach(Consumer<? super T>, Function<FastFuture, T>) - Method in class com.aol.simple.react.collectors.lazy.IncrementalReducer
 
forEach(Consumer<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
forEach(Consumer<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazyStream
 
forEachOrdered(Consumer<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
forEachResults(Collection<FastFuture<T>>, Consumer<? super T>, Function<FastFuture, T>) - Method in class com.aol.simple.react.collectors.lazy.IncrementalReducer
 
forwardErrors(Consumer<Throwable>) - Method in interface com.aol.simple.react.reactivestreams.FutureStreamAsyncPublisher
 
forwardErrors(Consumer<Throwable>) - Method in interface com.aol.simple.react.reactivestreams.FutureStreamSynchronousPublisher
 
forwardErrors(Consumer<Throwable>) - Method in class com.aol.simple.react.stream.lazy.LazyFutureStreamImpl
 
freeThread(T) - Static method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
Create a sequential synchronous stream that runs on the current thread
freeThread(T...) - Static method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
Create a sequential synchronous stream that runs on the current thread
freeThread(T) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Create a sequential synchronous stream that runs on a free thread (commonFreeThread executor by default, shared across any instances created in this manner.
freeThread(T...) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Create a sequential synchronous stream that runs on a free thread (commonFreeThread executor by default, shared across any instances created in this manner.
from(Iterator<U>) - Method in class com.aol.simple.react.stream.BaseSimpleReact
Start a reactive flow from a JDK Iterator
from(Collection<R>) - Method in class com.aol.simple.react.stream.BaseSimpleReact
Start a reactive flow from a Collection using an Iterator
from(Stream<U>) - Method in class com.aol.simple.react.stream.BaseSimpleReact
Start a reactive dataflow from a stream.
from(IntStream) - Method in class com.aol.simple.react.stream.BaseSimpleReact
Start a reactive dataflow from a stream.
from(DoubleStream) - Method in class com.aol.simple.react.stream.BaseSimpleReact
Start a reactive dataflow from a stream.
from(LongStream) - Method in class com.aol.simple.react.stream.BaseSimpleReact
Start a reactive dataflow from a stream.
from(CompletableFuture<U>) - Method in class com.aol.simple.react.stream.BaseSimpleReact
 
from(CompletableFuture<U>...) - Method in class com.aol.simple.react.stream.BaseSimpleReact
 
from(CompletableFuture<U>) - Method in class com.aol.simple.react.stream.lazy.LazyReact
 
from(CompletableFuture<U>...) - Method in class com.aol.simple.react.stream.lazy.LazyReact
 
from(Stream<U>) - Method in class com.aol.simple.react.stream.lazy.LazyReact
 
from(Iterator<U>) - Method in class com.aol.simple.react.stream.lazy.LazyReact
Start a reactive flow from a JDK Iterator
from(Collection<R>) - Method in class com.aol.simple.react.stream.lazy.LazyReact
Start a reactive flow from a Collection using an Iterator
from(IntStream) - Method in class com.aol.simple.react.stream.lazy.LazyReact
Start a reactive dataflow from a stream.
from(DoubleStream) - Method in class com.aol.simple.react.stream.lazy.LazyReact
Start a reactive dataflow from a stream.
from(LongStream) - Method in class com.aol.simple.react.stream.lazy.LazyReact
Start a reactive dataflow from a stream.
from(Stream<U>) - Method in class com.aol.simple.react.stream.simple.SimpleReact
Start a reactive dataflow from a stream.
from(Collection<R>) - Method in class com.aol.simple.react.stream.simple.SimpleReact
Start a reactive flow from a Collection using an Iterator
from(Iterator<U>) - Method in class com.aol.simple.react.stream.simple.SimpleReact
Start a reactive flow from a JDK Iterator
from(IntStream) - Method in class com.aol.simple.react.stream.simple.SimpleReact
Start a reactive dataflow from a stream.
from(DoubleStream) - Method in class com.aol.simple.react.stream.simple.SimpleReact
Start a reactive dataflow from a stream.
from(LongStream) - Method in class com.aol.simple.react.stream.simple.SimpleReact
Start a reactive dataflow from a stream.
from(CompletableFuture<U>) - Method in class com.aol.simple.react.stream.simple.SimpleReact
 
from(CompletableFuture<U>...) - Method in class com.aol.simple.react.stream.simple.SimpleReact
 
fromCompletableFuture(CompletableFuture<T>) - Static method in class com.aol.simple.react.async.future.FastFuture
Internal conversion method to convert CompletableFutures to FastFuture.
fromIterable(Iterable<U>) - Method in class com.aol.simple.react.stream.BaseSimpleReact
Start a reactive flow from a JDK Iterator
fromIterable(Iterable<U>) - Method in class com.aol.simple.react.stream.lazy.LazyReact
 
fromIterable(Iterable<U>) - Method in class com.aol.simple.react.stream.simple.SimpleReact
Start a reactive flow from a JDK Iterator
fromListCompletableFuture(List<CompletableFuture<R>>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
fromStream(Stream<T>) - Method in interface com.aol.simple.react.async.Adapter
 
fromStream(Stream<T>) - Method in class com.aol.simple.react.async.Queue
 
fromStream(Stream<T>) - Method in class com.aol.simple.react.async.Signal
 
fromStream(Stream<T>) - Method in class com.aol.simple.react.async.Topic
 
fromStream(Stream<CompletableFuture<U>>) - Method in class com.aol.simple.react.stream.BaseSimpleReact
Start a reactive dataflow from a stream of CompletableFutures.
fromStream(Stream<CompletableFuture<U>>) - Method in class com.aol.simple.react.stream.lazy.LazyReact
 
fromStream(Stream<CompletableFuture<U>>) - Method in class com.aol.simple.react.stream.simple.SimpleReact
Start a reactive dataflow from a stream of CompletableFutures.
fromStream(Stream<R>) - Method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
 
fromStream(Stream<R>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
fromStream(Stream<R>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
fromStreamCompletableFutureReplace(Stream<CompletableFuture<R>>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
fromStreamOfFutures(Stream<FastFuture<T>>) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
 
fromStreamOfFutures(Stream<FastFuture<T>>) - Method in class com.aol.simple.react.stream.traits.future.operators.OperationsOnFuturesImpl
 
fromStreamOfFutures(Stream<FastFuture<R>>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
fromStreamOfFutures(Stream<CompletableFuture<R>>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Construct a SimpleReactStream from provided Stream of CompletableFutures
functions - Variable in class com.aol.simple.react.async.future.FinalPipeline
 
futureOperations() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
futureOperations(Executor) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
FuturePool - Class in com.aol.simple.react.async.future.pool
Single consumer / multiple producer future pool
FuturePool() - Constructor for class com.aol.simple.react.async.future.pool.FuturePool
 
FutureStreamAsyncPublisher<T> - Interface in com.aol.simple.react.reactivestreams
Reactive Streams publisher that uses a separate thread (non-calling thread) to publish on
FutureStreamSubscriber<T> - Class in com.aol.simple.react.reactivestreams
Create a LazyFutureStream Subscriber to use
FutureStreamSubscriber() - Constructor for class com.aol.simple.react.reactivestreams.FutureStreamSubscriber
 
FutureStreamSynchronousPublisher<T> - Interface in com.aol.simple.react.reactivestreams
Reactive Streams publisher, that publishes on the calling thread

G

generate() - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Generate an infinite Stream of null values that runs on the current thread
generate(T) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Generate an infinite Stream of given value that runs on the current thread
generate(Supplier<T>) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Generate an infinite Stream of value returned from Supplier that runs on the current thread
get(K) - Static method in class com.aol.simple.react.async.pipes.Pipes
 
get() - Method in class com.aol.simple.react.async.Queue
 
get(long) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Gets the element at index, and returns a Tuple containing the element (it must be present) and a lazy copy of the Sequence for further processing.
getAllCompleted() - Method in class com.aol.simple.react.stream.Status
 
getAllResults() - Method in class com.aol.simple.react.collectors.lazy.BatchingCollector
 
getAllResults() - Method in class com.aol.simple.react.collectors.lazy.EmptyCollector
 
getAllResults() - Method in interface com.aol.simple.react.collectors.lazy.LazyResultConsumer
 
getAllResults() - Method in class com.aol.simple.react.collectors.lazy.SamplingCollector
 
getCompleted() - Method in class com.aol.simple.react.stream.Status
 
getElapsedMillis() - Method in class com.aol.simple.react.stream.Status
 
getElapsedNanos() - Method in class com.aol.simple.react.stream.Status
 
getElapsedNanoseconds() - Method in class com.aol.simple.react.util.SimpleTimer
 
getErrorHandler() - Method in interface com.aol.simple.react.stream.traits.BlockingStream
 
getErrorHandler() - Method in interface com.aol.simple.react.stream.traits.ConfigurableStream
 
getErrorHandler() - Method in interface com.aol.simple.react.stream.traits.LazyStream
 
getErrors() - Method in class com.aol.simple.react.stream.Status
 
getExec() - Method in interface com.aol.simple.react.stream.traits.future.operators.HasExec
 
getExecutor() - Method in class com.aol.simple.react.stream.BaseSimpleReact
 
getInput() - Method in class com.aol.simple.react.stream.pushable.AbstractPushableStream
 
getInput() - Method in class com.aol.simple.react.stream.pushable.MultiplePushableStreamsBuilder
 
getLastActive() - Method in interface com.aol.simple.react.reactivestreams.FutureStreamAsyncPublisher
 
getLastActive() - Method in interface com.aol.simple.react.reactivestreams.FutureStreamSynchronousPublisher
 
getLastActive() - Method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
 
getLastActive() - Method in interface com.aol.simple.react.stream.traits.BlockingStream
 
getLastActive() - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
 
getLastActive() - Method in class com.aol.simple.react.stream.traits.future.operators.OperationsOnFuturesImpl
 
getLastActive() - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
 
getLastActive() - Method in interface com.aol.simple.react.stream.traits.LazyStream
 
getLastActive() - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
getLazyCollector() - Method in interface com.aol.simple.react.stream.traits.LazyStream
 
getLazyExecutor() - Static method in class com.aol.simple.react.stream.ThreadPools
 
getMaxActive() - Method in interface com.aol.simple.react.stream.traits.LazyStream
 
getParallelReduction() - Method in interface com.aol.simple.react.stream.traits.LazyStream
 
getPopulator() - Method in class com.aol.simple.react.stream.lazy.LazyFutureStreamImpl
 
getPopulator() - Method in interface com.aol.simple.react.stream.traits.LazyToQueue
 
getPublisherExecutor() - Method in interface com.aol.simple.react.reactivestreams.FutureStreamAsyncPublisher
 
getQueueFactory() - Method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
 
getQueueFactory() - Method in interface com.aol.simple.react.stream.traits.EagerToQueue
 
getQueueFactory() - Method in interface com.aol.simple.react.stream.traits.ToQueue
 
getResults() - Method in class com.aol.simple.react.collectors.lazy.BatchingCollector
 
getResults() - Method in class com.aol.simple.react.collectors.lazy.EmptyCollector
 
getResults() - Method in interface com.aol.simple.react.collectors.lazy.LazyResultConsumer
 
getResults() - Method in class com.aol.simple.react.collectors.lazy.SamplingCollector
 
getResultsSoFar() - Method in class com.aol.simple.react.stream.Status
 
getRetrier() - Method in class com.aol.simple.react.stream.BaseSimpleReact
 
getRetrier() - Method in class com.aol.simple.react.stream.lazy.LazyFutureStreamImpl
 
getRetrier() - Method in class com.aol.simple.react.stream.simple.SimpleReactStreamImpl
 
getRetrier() - Method in interface com.aol.simple.react.stream.traits.ConfigurableStream
 
getSafe(FastFuture, Optional<Consumer<Throwable>>) - Static method in class com.aol.simple.react.stream.traits.BlockingStreamHelper
 
getSequential() - Static method in class com.aol.simple.react.stream.ThreadPools
 
getSequentialRetry() - Static method in class com.aol.simple.react.stream.ThreadPools
 
getSimpleReact() - Method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
 
getSimpleReact() - Method in interface com.aol.simple.react.stream.traits.ConfigurableStream
 
getSimpleReact() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
getSimpleReact() - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
 
getSimpleReact() - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
getSizeSignal() - Method in class com.aol.simple.react.async.Topic
 
getStandard() - Static method in class com.aol.simple.react.stream.ThreadPools
 
getStandardRetry() - Static method in class com.aol.simple.react.stream.ThreadPools
 
getStream() - Method in class com.aol.simple.react.stream.pushable.AbstractPushableStream
 
getStream() - Method in interface com.aol.simple.react.stream.traits.future.operators.HasStream
 
getSubscription() - Method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
 
getSubscription() - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
 
getSubscription() - Method in class com.aol.simple.react.stream.traits.future.operators.OperationsOnFuturesImpl
 
getSubscription() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
getSubscription() - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
 
getSubscription() - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
getTargetClass() - Method in class com.aol.simple.react.monad.LazyFutureStreamComprehender
 
getTargetClass() - Method in class com.aol.simple.react.monad.SimpleReactStreamComprehender
 
getTaskExecutor() - Method in class com.aol.simple.react.stream.lazy.LazyFutureStreamImpl
 
getTaskExecutor() - Method in class com.aol.simple.react.stream.simple.SimpleReactStreamImpl
 
getTaskExecutor() - Method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
 
getTaskExecutor() - Method in interface com.aol.simple.react.stream.traits.ConfigurableStream
 
getTotal() - Method in class com.aol.simple.react.stream.Status
 
getValue() - Method in exception com.aol.simple.react.exceptions.SimpleReactFailedStageException
 
groupBy(Function<? super U, ? extends K>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
grouped(int) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Group elements in a Stream
grouped(int) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 

H

handleContinuation() - Method in interface com.aol.simple.react.async.ContinuationStrategy
 
handleContinuation() - Method in class com.aol.simple.react.async.SingleContinuation
 
handleContinuation() - Method in class com.aol.simple.react.async.StreamOfContinuations
 
handleExceptions(Function<U, R>) - Static method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
 
handleExceptions(Function<U, R>) - Static method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
hasCapacity(int) - Method in class com.aol.simple.react.collectors.lazy.EmptyCollector
 
HasExec - Interface in com.aol.simple.react.stream.traits.future.operators
 
hashCode() - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
hasNext() - Method in class com.aol.simple.react.stream.CloseableIterator
 
HasStream<T> - Interface in com.aol.simple.react.stream.traits.future.operators
 
headAndTail() - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
extract head and tail together, where head is expected to be present
headAndTail() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
headAndTailOptional() - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
extract head and tail together, where no head or tail may be present
headAndTailOptional() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
hotStream(Executor) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
hotStream() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Turns this LazyFutureStream into a HotStream, a connectable Stream, being executed on a thread on the in it's current task executor, that is producing data

I

IncrementalReducer<T> - Class in com.aol.simple.react.collectors.lazy
Perform incremental (optionally parallel) reduction on a stream
IncrementalReducer() - Constructor for class com.aol.simple.react.collectors.lazy.IncrementalReducer
 
InfiniteClosingSpliterator<T> - Class in com.aol.simple.react.stream
 
InfiniteClosingSpliterator(long, Supplier<T>, Continueable, Queue) - Constructor for class com.aol.simple.react.stream.InfiniteClosingSpliterator
 
InfiniteClosingSpliterator(long, Supplier<T>, Continueable) - Constructor for class com.aol.simple.react.stream.InfiniteClosingSpliterator
 
InfiniteClosingSpliteratorFromIterator<T> - Class in com.aol.simple.react.stream
 
InfiniteClosingSpliteratorFromIterator(long, Iterator<T>, Continueable) - Constructor for class com.aol.simple.react.stream.InfiniteClosingSpliteratorFromIterator
 
InfiniteProcessingException - Exception in com.aol.simple.react.stream
 
InfiniteProcessingException(String) - Constructor for exception com.aol.simple.react.stream.InfiniteProcessingException
 
injectFutures() - Method in class com.aol.simple.react.stream.LazyStreamWrapper
 
injectFuturesSeq() - Method in class com.aol.simple.react.stream.LazyStreamWrapper
 
innerJoin(Stream<T>, BiPredicate<U, T>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Inner join 2 streams into one.
insertAt(int, T...) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Insert data into a stream at given position
insertAt(int, U...) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
insertStreamAt(int, Stream<T>) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Insert a Stream into the middle of this stream at the specified position
insertStreamAt(int, Stream<U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
insertStreamFuturesAt(int, Stream<CompletableFuture<T>>) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Insert a Stream into the middle of this stream at the specified position
intersperse(U) - Method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
Returns a stream with a given value interspersed between any two values of this stream.
intersperse(T) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Returns a stream with a given value interspersed between any two values of this stream.
intersperse(CompletableFuture<T>) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Returns a stream with a given value interspersed between any two values of this stream.
intersperse(U) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Returns a stream with a given value interspersed between any two values of this stream.
IO - Static variable in class com.aol.simple.react.config.MaxActive
 
ioReact - Static variable in class com.aol.simple.react.async.pipes.EagerReactors
 
ioReact - Static variable in class com.aol.simple.react.async.pipes.LazyReactors
 
ioStream() - Method in interface com.aol.simple.react.mixins.LazyReactive
 
isAsync() - Method in class com.aol.simple.react.stream.BaseSimpleReact
 
isAsync() - Method in class com.aol.simple.react.stream.lazy.LazyFutureStreamImpl
 
isAsync() - Method in class com.aol.simple.react.stream.lazy.LazyReact
 
isAsync() - Method in class com.aol.simple.react.stream.simple.SimpleReact
 
isAsync() - Method in class com.aol.simple.react.stream.simple.SimpleReactStreamImpl
 
isAsync() - Method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
 
isAsync() - Method in interface com.aol.simple.react.stream.traits.ConfigurableStream
 
isDataPresent() - Method in exception com.aol.simple.react.async.Queue.ClosedQueueException
 
isEmpty() - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
isOpen() - Method in class com.aol.simple.react.async.Queue
 
isOpen() - Method in class com.aol.simple.react.async.Queue.QueueReader
 
isParallel() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
isSequential() - Method in class com.aol.simple.react.async.future.ExecutionPipeline
 
isSequential() - Method in class com.aol.simple.react.async.future.PipelineBuilder
 
isSequential() - Method in class com.aol.simple.react.stream.LazyStreamWrapper
 
isUseCommon() - Static method in class com.aol.simple.react.stream.ThreadPools
 
iterate(T, UnaryOperator<T>) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
iterateInfinitely(U, UnaryOperator<U>) - Method in class com.aol.simple.react.stream.lazy.LazyReact
Iterate infinitely using the supplied seed and function
iterator() - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
iterator() - Method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
 
iterator() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 

J

JDKReactiveStreamsPublisher<T> - Class in com.aol.simple.react.reactivestreams
ReactiveStreams publisher for standard Java 8 Stream implementations including java.util.stream.Stream jool.Seq cyclops.SequenceM This provides both Asynchronous (external thread) and Synchronous (calling thread) publishing
JDKReactiveStreamsPublisher() - Constructor for class com.aol.simple.react.reactivestreams.JDKReactiveStreamsPublisher
 
JDKReactiveStreamsSubscriber<T> - Class in com.aol.simple.react.reactivestreams
ReactiveStreams subscriber for standard Java 8 Stream implementations including
JDKReactiveStreamsSubscriber() - Constructor for class com.aol.simple.react.reactivestreams.JDKReactiveStreamsSubscriber
 
jitter(long) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Introduce a random delay between events in a stream Can be used to prevent behaviour synchronizing within a system
join() - Method in class com.aol.simple.react.async.future.FastFuture
Join which can be called exactly once!
join() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
join(String) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
join(String, String, String) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
join(SimpleReactStream<BaseSimpleReactStream<U>>) - Static method in interface com.aol.simple.react.stream.traits.SimpleReactStream
flatten nested SimpleReactStreams

L

last() - Static method in class com.aol.simple.react.extractors.Extractors
 
last() - Method in interface com.aol.simple.react.stream.traits.BlockingStream
Block until all results received.
lastActiveArray(EagerStreamWrapper) - Static method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
LazyFutureStream<U> - Interface in com.aol.simple.react.stream.traits
Lazy Stream Factory methods
lazyFutureStream(CompletableFuture<T>) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Create a 'free threaded' asynchronous stream that runs on the supplied CompletableFutures executor service (unless async operator invoked , in which it will switch to the common 'free' thread executor) Subsequent tasks will be executed synchronously unless the async() operator is invoked.
lazyFutureStream(CompletableFuture<T>...) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Create a 'free threaded' asynchronous stream that runs on a single thread (not current) The supplier will be executed asyncrhonously, subsequent tasks will be executed synchronously unless the async() operator is invoked.
lazyFutureStream(Stream<T>) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Wrap a Stream into a FutureStream that runs on the current thread
lazyFutureStream(Iterator<T>) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Wrap an Iterator into a FutureStream that runs on the current thread
LazyFutureStreamComprehender - Class in com.aol.simple.react.monad
Cyclops Monad Comprehender for LazyFutureStreams
LazyFutureStreamComprehender() - Constructor for class com.aol.simple.react.monad.LazyFutureStreamComprehender
 
lazyFutureStreamFrom(Stream<CompletableFuture<T>>) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Create a 'free threaded' asynchronous stream that runs on the supplied CompletableFutures executor service (unless async operator invoked , in which it will switch to the common 'free' thread executor) Subsequent tasks will be executed synchronously unless the async() operator is invoked.
lazyFutureStreamFromIterable(Iterable<T>) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Wrap an Iterable into a FutureStream that runs on the current thread
LazyFutureStreamFunctions - Class in com.aol.simple.react.stream.traits
 
LazyFutureStreamFunctions() - Constructor for class com.aol.simple.react.stream.traits.LazyFutureStreamFunctions
 
LazyFutureStreamImpl<U> - Class in com.aol.simple.react.stream.lazy
 
LazyFutureStreamImpl(LazyReact, Stream<U>) - Constructor for class com.aol.simple.react.stream.lazy.LazyFutureStreamImpl
 
LazyReact - Class in com.aol.simple.react.stream.lazy
Builder class for LazyFutureStreams react methods - submit Suppliers to task executor of methods - build Streams directly from data
LazyReact() - Constructor for class com.aol.simple.react.stream.lazy.LazyReact
Construct a LazyReact builder using standard thread pool.
LazyReact(Executor) - Constructor for class com.aol.simple.react.stream.lazy.LazyReact
Construct a LazyReact builder with provided Executor
LazyReact(int, int) - Constructor for class com.aol.simple.react.stream.lazy.LazyReact
LazyReact builder with a new TaskExecutor with threads determined by threadPoolSize Max concurrent tasks is determined by concurrency
LazyReact(Executor, RetryExecutor, Boolean, MaxActive, Executor, boolean, boolean, boolean, boolean, Cacheable) - Constructor for class com.aol.simple.react.stream.lazy.LazyReact
 
LazyReact(Executor, AsyncRetryExecutor, boolean, MaxActive) - Constructor for class com.aol.simple.react.stream.lazy.LazyReact
 
lazyReact - Static variable in class com.aol.simple.react.threads.ParallelElasticPools
 
lazyReact - Static variable in class com.aol.simple.react.threads.SequentialElasticPools
 
LazyReactive - Interface in com.aol.simple.react.mixins
Mixin / Trait for Reactive behaviour via simple-react
LazyReactors - Class in com.aol.simple.react.async.pipes
 
LazyReactors() - Constructor for class com.aol.simple.react.async.pipes.LazyReactors
 
LazyResultConsumer<T> - Interface in com.aol.simple.react.collectors.lazy
Interface that defines the rules for Collecting results from Infinite SimpleReact Streams
LazySimpleReactStream<U> - Interface in com.aol.simple.react.stream.traits
 
LazyStream<U> - Interface in com.aol.simple.react.stream.traits
 
LazyStreamWrapper<U> - Class in com.aol.simple.react.stream
 
LazyStreamWrapper(Stream, LazyReact) - Constructor for class com.aol.simple.react.stream.LazyStreamWrapper
 
LazyToQueue<U> - Interface in com.aol.simple.react.stream.traits
 
leftOuterJoin(Stream<T>, BiPredicate<U, T>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Left outer join 2 streams into one.
liftOptional() - Method in class com.aol.simple.react.stream.traits.operators.BatchBySize
 
liftOptional() - Method in class com.aol.simple.react.stream.traits.operators.BatchByTime
 
liftOptional() - Method in class com.aol.simple.react.stream.traits.operators.BatchByTimeAndSize
 
liftOptional() - Method in class com.aol.simple.react.stream.traits.operators.Debounce
 
liftOptional() - Method in class com.aol.simple.react.stream.traits.operators.OnePer
 
limit(long) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
assertThat(of(1,2,3,4,5).actOnFutures().limit(2).collect(Collectors.toList()).size(),is(2));
limit(long) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
limit(long, TimeUnit) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
limit(long) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Perform a limit operation on the underlying Stream of Futures In contrast to EagerFutureStream#limit this removes entries basaed on their start position
limitLast(int) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Limit results to the last x elements in a SequenceM
limitLast(int) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
limitUntil(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Returns a stream limited to all elements for which a predicate evaluates to false.
limitWhile(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Returns a stream limited to all elements for which a predicate evaluates to true.
list() - Method in class com.aol.simple.react.stream.EagerStreamWrapper
 

M

map(LazyFutureStream, Function) - Method in class com.aol.simple.react.monad.LazyFutureStreamComprehender
 
map(SimpleReactStream, Function) - Method in class com.aol.simple.react.monad.SimpleReactStreamComprehender
 
map(Function<? super U, ? extends R>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
mapReduce(Monoid<R>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
mapReduce(Function<? super U, ? extends R>, Monoid<R>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
mapToDouble(ToDoubleFunction<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
mapToInt(ToIntFunction<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
mapToLong(ToLongFunction<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
markComplete() - Method in class com.aol.simple.react.async.future.FastFuture
 
max(Comparator<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
MaxActive - Class in com.aol.simple.react.config
 
MaxActive() - Constructor for class com.aol.simple.react.config.MaxActive
 
maxActive(int) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Configure the max active concurrent tasks.
maxBy(Function<U, C>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
merge(SimpleReactStream<U>...) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
merge(SimpleReactStream, SimpleReactStream) - Static method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Merge this reactive dataflow with another - recommended for merging different types.
mergeLatest(LazyFutureStream<?>...) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Merges this stream and the supplied Streams into a single Stream where the next value is the next returned across any of the involved Streams.
min(Comparator<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
minBy(Function<U, C>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
MISSING_VALUE - Static variable in class com.aol.simple.react.stream.MissingValue
 
MissingValue - Class in com.aol.simple.react.stream
 
MissingValue() - Constructor for class com.aol.simple.react.stream.MissingValue
 
multiple() - Method in class com.aol.simple.react.stream.pushable.PushableStreamBuilder
 
MultiplePushableStreamsBuilder<T> - Class in com.aol.simple.react.stream.pushable
Build Streams that stream data from the topic instance

N

next(Supplier<FastFuture<T>>) - Method in class com.aol.simple.react.async.future.pool.FuturePool
 
next() - Method in class com.aol.simple.react.async.Queue.QueueReader
 
next() - Method in class com.aol.simple.react.stream.CloseableIterator
 
nextReactor() - Method in class com.aol.simple.react.threads.ReactPool
 
NIL() - Constructor for class com.aol.simple.react.async.Queue.NIL
 
NILL - Static variable in class com.aol.simple.react.async.Queue
 
noneMatch(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
notEmpty() - Method in class com.aol.simple.react.async.Queue.QueueReader
 
NoWaitRetry<T> - Class in com.aol.simple.react.async.wait
Repeatedly retry to take or offer element to Queue if full or data unavailable
NoWaitRetry() - Constructor for class com.aol.simple.react.async.wait.NoWaitRetry
 
NULL - Static variable in class com.aol.simple.react.stream.traits.NullValue
 
NullValue - Class in com.aol.simple.react.stream.traits
 
NullValue() - Constructor for class com.aol.simple.react.stream.traits.NullValue
 

O

objectPoolingOff() - Method in class com.aol.simple.react.stream.lazy.LazyReact
Turn objectPooling off for any Streams created by the returned LazyReact builder.
objectPoolingOn() - Method in class com.aol.simple.react.stream.lazy.LazyReact
Turn objectPooling on for any Streams created by the returned LazyReact builder This improves performance for Streams with very large numbers of elements, by reusing Future instances.
of(T...) - Method in class com.aol.simple.react.mixins.OptimizedLazyReact
Generate a FutureStream from the specified elements.
of(Stream<T>) - Method in class com.aol.simple.react.mixins.OptimizedLazyReact
Generate a FutureStream from the specified Stream.
of(Collection<T>) - Method in class com.aol.simple.react.mixins.OptimizedLazyReact
Generate a FutureStream from the specified Collection.
of(Object) - Method in class com.aol.simple.react.monad.LazyFutureStreamComprehender
 
of(Object) - Method in class com.aol.simple.react.monad.SimpleReactStreamComprehender
 
of(U...) - Method in class com.aol.simple.react.stream.BaseSimpleReact
 
of(U...) - Method in class com.aol.simple.react.stream.lazy.LazyReact
 
of(U...) - Method in class com.aol.simple.react.stream.simple.SimpleReact
 
of(T) - Static method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
Create a sequential synchronous stream that runs on the current thread
of(T...) - Static method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
Create a sequential synchronous stream that runs on the current thread
of(T) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Create a sequential synchronous stream that runs on the current thread
of(T...) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Create a sequential synchronous stream that runs on the current thread
ofAsync(Stream<T>, Executor) - Static method in class com.aol.simple.react.reactivestreams.JDKReactiveStreamsPublisher
This creates an asynchronous publisher that publishes on an external thread
offer(T) - Method in interface com.aol.simple.react.async.Adapter
Offer a single datapoint to this adapter
offer(Object) - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
offer(Object, long, TimeUnit) - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
offer(T) - Method in class com.aol.simple.react.async.Queue
Offer a single datapoint to this Queue If the queue is a bounded queue and is full it will block until space comes available or until offer time out is reached (default is Integer.MAX_VALUE DAYS).
offer(T) - Method in class com.aol.simple.react.async.Topic
Add a single datapoint to this Queue
offer(WaitStrategy.Offerable) - Method in class com.aol.simple.react.async.wait.DirectWaitStrategy
 
offer(WaitStrategy.Offerable) - Method in class com.aol.simple.react.async.wait.ExponentialBackofWaitStrategy
 
offer(WaitStrategy.Offerable) - Method in class com.aol.simple.react.async.wait.NoWaitRetry
 
offer(WaitStrategy.Offerable) - Method in class com.aol.simple.react.async.wait.SpinWait
 
offer(WaitStrategy.Offerable) - Method in interface com.aol.simple.react.async.wait.WaitStrategy
 
offer() - Method in interface com.aol.simple.react.async.wait.WaitStrategy.Offerable
 
offer(WaitStrategy.Offerable) - Method in class com.aol.simple.react.async.wait.YieldWait
 
ofIterable(Iterable<T>) - Method in class com.aol.simple.react.mixins.OptimizedLazyReact
Generate a FutureStream from the specified Iterable.
ofSync(Stream<T>) - Static method in class com.aol.simple.react.reactivestreams.JDKReactiveStreamsPublisher
This creates a synchronous publisher that publishes on the calling thread.
ofType(Class<U>) - Method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
Keep only those elements in a stream that are of a given type.
ofType(Class<U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Keep only those elements in a stream that are of a given type.
onClose(Runnable) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
onComplete(Consumer<FastFuture.OnComplete>) - Method in class com.aol.simple.react.async.future.FastFuture
Called at least once on complete
OnComplete() - Constructor for class com.aol.simple.react.async.future.FastFuture.OnComplete
 
onComplete() - Method in class com.aol.simple.react.reactivestreams.FutureStreamSubscriber
 
onComplete() - Method in class com.aol.simple.react.reactivestreams.JDKReactiveStreamsSubscriber
 
onEmpty(U) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Produce this stream, or an alternative stream from the value, in case this stream is empty.
onEmptyGet(Supplier<U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Produce this stream, or an alternative stream from the supplier, in case this stream is empty.
onEmptyThrow(Supplier<X>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Produce this stream, or an alternative stream from the supplier, in case this stream is empty.
onePer(long, TimeUnit) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Slow emissions down, emiting one element per specified time period
OnePer<U> - Class in com.aol.simple.react.stream.traits.operators
 
OnePer() - Constructor for class com.aol.simple.react.stream.traits.operators.OnePer
 
onError(Throwable) - Method in class com.aol.simple.react.reactivestreams.FutureStreamSubscriber
 
onError(Throwable) - Method in class com.aol.simple.react.reactivestreams.JDKReactiveStreamsSubscriber
 
onFail(Consumer<Throwable>) - Method in class com.aol.simple.react.async.future.ExecutionPipeline
 
onFail - Variable in class com.aol.simple.react.async.future.FinalPipeline
 
onFail(Consumer<Throwable>) - Method in class com.aol.simple.react.async.future.PipelineBuilder
 
onFail(Function<SimpleReactFailedStageException, U>) - Method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
React onFail Define a function that can be used to recover from exceptions during the preceeding stage of the dataflow.
onFail(Class<? extends Throwable>, Function<SimpleReactFailedStageException, U>) - Method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
Recover for a particular class of exceptions only.
onFail(Function<SimpleReactFailedStageException, U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
onFail(Class<? extends Throwable>, Function<SimpleReactFailedStageException, U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
onFail(Function<SimpleReactFailedStageException, U>) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
React onFail Define a function that can be used to recover from exceptions during the preceeding stage of the dataflow.
onFail(Class<? extends Throwable>, Function<SimpleReactFailedStageException, U>) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
Recover for a particular class of exceptions only.
onFail(Function<SimpleReactFailedStageException, U>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
React onFail Define a function that can be used to recover from exceptions during the preceeding stage of the dataflow.
onFail(Class<? extends Throwable>, Function<SimpleReactFailedStageException, U>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Recover for a particular class of exceptions only.
onNext(T) - Method in class com.aol.simple.react.reactivestreams.FutureStreamSubscriber
 
onNext(T) - Method in class com.aol.simple.react.reactivestreams.JDKReactiveStreamsSubscriber
 
onSubscribe(Subscription) - Method in class com.aol.simple.react.reactivestreams.FutureStreamSubscriber
 
onSubscribe(Subscription) - Method in class com.aol.simple.react.reactivestreams.JDKReactiveStreamsSubscriber
 
operation(Function<PipelineBuilder, PipelineBuilder>) - Method in class com.aol.simple.react.stream.LazyStreamWrapper
 
OperationsOnFutures<T> - Interface in com.aol.simple.react.stream.traits.future.operators
 
OperationsOnFuturesImpl<T> - Class in com.aol.simple.react.stream.traits.future.operators
 
OperationsOnFuturesImpl() - Constructor for class com.aol.simple.react.stream.traits.future.operators.OperationsOnFuturesImpl
 
OptimizedLazyReact - Class in com.aol.simple.react.mixins
Builder of LazyFutureStreams
OptimizedLazyReact() - Constructor for class com.aol.simple.react.mixins.OptimizedLazyReact
 

P

parallel(U...) - Static method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
Construct an SimpleReactStream from specified array, that will run in parallel on the common Parallel executor service (by default the Common ForkJoinPool) see ThreadPools#setUseCommon to change to a different pool
parallel() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
parallel(U...) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Construct an parallel LazyFutureStream from specified array, using the configured standard parallel thread pool.
parallelBuilder() - Static method in class com.aol.simple.react.stream.lazy.LazyReact
 
parallelBuilder(int) - Static method in class com.aol.simple.react.stream.lazy.LazyReact
Construct a new LazyReact builder, with a new task executor and retry executor with configured number of threads
parallelBuilder() - Static method in class com.aol.simple.react.stream.simple.SimpleReact
 
parallelBuilder(int) - Static method in class com.aol.simple.react.stream.simple.SimpleReact
Construct a new SimpleReact builder, with a new task executor and retry executor with configured number of threads
parallelCommonBuilder() - Static method in class com.aol.simple.react.stream.lazy.LazyReact
 
parallelCommonBuilder() - Static method in class com.aol.simple.react.stream.simple.SimpleReact
 
ParallelElasticPools - Class in com.aol.simple.react.threads
A ReactPool of each type for parallel Streams Thread pool will be sized to number of processors
ParallelElasticPools() - Constructor for class com.aol.simple.react.threads.ParallelElasticPools
 
parallelism(int) - Method in class com.aol.simple.react.RetryBuilder
 
ParallelReductionConfig - Class in com.aol.simple.react.stream.lazy
Configuration for incremental parallel reduction batchSize and parallel indicates whether parallel reduction is enabled
ParallelReductionConfig() - Constructor for class com.aol.simple.react.stream.lazy.ParallelReductionConfig
 
parallelStream() - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
partition(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Partition a stream in two given a predicate.
partitionFutureStream(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Partition an LazyFutureStream into two LazyFutureStreams given a predicate.
partitionSequence(Predicate<U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
peek() - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
peek(Consumer<T>) - Method in class com.aol.simple.react.async.future.ExecutionPipeline
 
peek(Consumer<T>) - Method in class com.aol.simple.react.async.future.PipelineBuilder
 
peek(Consumer<? super U>) - Method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
Peek asynchronously at the results in the current stage.
peek(Consumer<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
peek(Consumer<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
Peek asynchronously at the results in the current stage.
peek(Consumer<? super U>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Peek asynchronously at the results in the current stage.
peekSync(Consumer<? super U>) - Method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
Synchronous peek operator
peekSync(Consumer<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
peekSync(Consumer<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
Synchronous peek operator
peekSync(Consumer<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazyToQueue
 
peekSync(Consumer<? super U>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Synchronous peek operator
PipelineBuilder - Class in com.aol.simple.react.async.future
 
PipelineBuilder() - Constructor for class com.aol.simple.react.async.future.PipelineBuilder
 
PipelineBuilder(boolean, Executor, boolean, Cacheable) - Constructor for class com.aol.simple.react.async.future.PipelineBuilder
 
Pipes - Class in com.aol.simple.react.async.pipes
Store for Pipes for cross-thread communication
Pipes() - Constructor for class com.aol.simple.react.async.pipes.Pipes
 
PipesToLazyStreams - Class in com.aol.simple.react.async.pipes
 
PipesToLazyStreams() - Constructor for class com.aol.simple.react.async.pipes.PipesToLazyStreams
 
poll() - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
poll(long, TimeUnit) - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
poll(long, TimeUnit) - Method in class com.aol.simple.react.async.Queue
 
populate(REACTOR) - Method in class com.aol.simple.react.threads.ReactPool
 
populateFromCompletableFuture(CompletableFuture<T>) - Method in class com.aol.simple.react.async.future.FastFuture
 
prepend(T...) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Prepend given values to the start of the Stream
prepend(U...) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
prependFutures(CompletableFuture<T>...) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
List<String> result = of(1,2,3).actOnFutures() .prependFutures(CompletableFuture.completedFuture(100),CompletableFuture.completedFuture(200),CompletableFuture.completedFuture(300)) .map(it ->it+"!!") .collect(Collectors.toList()); assertThat(result,equalTo(Arrays.asList("100!!","200!!","300!!","1!!","2!!","3!!")));
prependStream(Stream<T>) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Prepend Stream to this SequenceM
prependStream(Stream<U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
prependStreamFutures(Stream<CompletableFuture<T>>) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Stream<CompletableFuture<Integer>> streamOfFutures = Stream.of(CompletableFuture.completedFuture(100),CompletableFuture.completedFuture(200),CompletableFuture.completedFuture(300)); List<String> result = of(1,2,3).actOnFutures() .prependStreamFutures(streamOfFutures) .map(it ->it+"!!") .collect(Collectors.toList()); assertThat(result,equalTo(Arrays.asList("100!!","200!!","300!!","1!!","2!!","3!!")));
priority - Static variable in class com.aol.simple.react.monad.LazyFutureStreamComprehender
 
priority() - Method in class com.aol.simple.react.monad.LazyFutureStreamComprehender
 
priority - Static variable in class com.aol.simple.react.monad.SimpleReactStreamComprehender
 
priority() - Method in class com.aol.simple.react.monad.SimpleReactStreamComprehender
 
proceed() - Method in class com.aol.simple.react.stream.traits.Continuation
 
publisher(Object, Executor) - Static method in class com.aol.simple.react.async.pipes.Pipes
 
publisher(Object) - Static method in class com.aol.simple.react.async.pipes.Pipes
 
PublisherForCyclops<T> - Class in com.aol.simple.react.reactivestreams.sequenceM
 
PublisherForCyclops() - Constructor for class com.aol.simple.react.reactivestreams.sequenceM.PublisherForCyclops
 
publishTo(Object, Publisher<T>) - Static method in class com.aol.simple.react.async.pipes.Pipes
 
publishToAsync(Object, Publisher<T>) - Static method in class com.aol.simple.react.async.pipes.Pipes
 
pushable(ReactPool<LazyReact>) - Method in class com.aol.simple.react.stream.pushable.MultiplePushableStreamsBuilder
Create a pushable LazyFutureStream using the supplied ReactPool
pushable(ReactPool<LazyReact>) - Method in class com.aol.simple.react.stream.pushable.PushableStreamBuilder
Create a pushable LazyFutureStream using the supplied ReactPool
pushableLazyFutureStream() - Method in class com.aol.simple.react.stream.pushable.MultiplePushableStreamsBuilder
Create a pushable LazyFutureStream.
PushableLazyFutureStream<T> - Class in com.aol.simple.react.stream.pushable
A more concrete Tuple2 impl v1 is Queue<T> v2 is LazyFutureStream<T>
PushableLazyFutureStream(Queue<T>, LazyFutureStream<T>) - Constructor for class com.aol.simple.react.stream.pushable.PushableLazyFutureStream
 
pushableLazyFutureStream() - Method in class com.aol.simple.react.stream.pushable.PushableStreamBuilder
Create a pushable LazyFutureStream.
pushableLazyFutureStream(Adapter<T>) - Method in class com.aol.simple.react.stream.pushable.PushableStreamBuilder
Create a LazyFutureStream.
pushableSeq() - Method in class com.aol.simple.react.stream.pushable.MultiplePushableStreamsBuilder
Create a pushable org.jooq.lambda.Seq
PushableSeq<T> - Class in com.aol.simple.react.stream.pushable
A more concrete Tuple2 impl v1 is Queue<T> v2 is Seq<T>
PushableSeq(Queue<T>, Seq<T>) - Constructor for class com.aol.simple.react.stream.pushable.PushableSeq
 
pushableSeq() - Method in class com.aol.simple.react.stream.pushable.PushableStreamBuilder
Create a pushable org.jooq.lambda.Seq
pushableSeq(Adapter<T>) - Method in class com.aol.simple.react.stream.pushable.PushableStreamBuilder
Create a pushable org.jooq.lambda.Seq
pushableStream() - Method in class com.aol.simple.react.stream.pushable.MultiplePushableStreamsBuilder
Create a pushable JDK 8 Stream
PushableStream<T> - Class in com.aol.simple.react.stream.pushable
A more concrete Tuple2 impl v1 is Queue<T> v2 is Stream<T>
PushableStream(Queue<T>, Stream<T>) - Constructor for class com.aol.simple.react.stream.pushable.PushableStream
 
pushableStream() - Method in class com.aol.simple.react.stream.pushable.PushableStreamBuilder
Create a pushable JDK 8 Stream
pushableStream(Adapter<T>) - Method in class com.aol.simple.react.stream.pushable.PushableStreamBuilder
Create a JDK 8 Stream from the supplied Adapter
PushableStreamBuilder - Class in com.aol.simple.react.stream.pushable
Create Java 8 Streams that data can be pushed into
PushableStreamBuilder() - Constructor for class com.aol.simple.react.stream.pushable.PushableStreamBuilder
 
put(Object) - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 

Q

quadruplicate() - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Makes four copies of a Stream Buffers intermediate values, leaders may change positions so a limit can be safely applied to the leading stream.
quadruplicate() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
Queue<T> - Class in com.aol.simple.react.async
Inspired by scalaz-streams async.Queue (functionally similar, but Blocking) A Queue that takes data from one or more input Streams and provides them to one or more output Streams Interface specifies a BlockingQueue, but NonBlockingQueues (such as ConcurrentLinkedQueue can be used in conjunction with an implementation of the Continuation interface
Queue() - Constructor for class com.aol.simple.react.async.Queue
Construct a Queue backed by a LinkedBlockingQueue
Queue(BlockingQueue<T>) - Constructor for class com.aol.simple.react.async.Queue
Queue accepts a BlockingQueue to make use of Blocking semantics
Queue(Queue<T>, WaitStrategy<T>, WaitStrategy<T>) - Constructor for class com.aol.simple.react.async.Queue
 
queue - Variable in class com.aol.simple.react.reactivestreams.FutureStreamSubscriber
 
queue - Variable in class com.aol.simple.react.reactivestreams.JDKReactiveStreamsSubscriber
 
Queue.ClosedQueueException - Exception in com.aol.simple.react.async
Exception thrown if Queue closed
Queue.NIL - Class in com.aol.simple.react.async
 
Queue.QueueReader<T> - Class in com.aol.simple.react.async
 
Queue.QueueTimeoutException - Exception in com.aol.simple.react.async
Exception thrown if Queue polling timesout
queueBackedSignal() - Static method in class com.aol.simple.react.async.Signal
 
QueueFactories - Class in com.aol.simple.react.async.factories
 
QueueFactories() - Constructor for class com.aol.simple.react.async.factories.QueueFactories
 
QueueFactory<T> - Interface in com.aol.simple.react.async.factories
 
QueueReader() - Constructor for class com.aol.simple.react.async.Queue.QueueReader
 
QueueTimeoutException() - Constructor for exception com.aol.simple.react.async.Queue.QueueTimeoutException
 
QueueToBlockingQueueWrapper - Class in com.aol.simple.react.async.factories
 
QueueToBlockingQueueWrapper() - Constructor for class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 

R

range(int, int) - Method in class com.aol.simple.react.stream.BaseSimpleReact
 
range(int, int) - Method in class com.aol.simple.react.stream.lazy.LazyReact
 
range(int, int) - Method in class com.aol.simple.react.stream.simple.SimpleReact
 
react(Supplier<T>...) - Method in class com.aol.simple.react.mixins.OptimizedLazyReact
Generate a FutureStream from the specified Suppliers.
react(Stream<Supplier<T>>) - Method in class com.aol.simple.react.mixins.OptimizedLazyReact
Generate a FutureStream from the specified Stream of Suppliers.
react(Collection<Supplier<T>>) - Method in class com.aol.simple.react.mixins.OptimizedLazyReact
Generate a FutureStream from the specified Collection of Suppliers.
react(Collection<Supplier<U>>) - Method in class com.aol.simple.react.stream.BaseSimpleReact
Start a reactive dataflow with a list of one-off-suppliers
react(Stream<Supplier<U>>) - Method in class com.aol.simple.react.stream.BaseSimpleReact
Start a reactive dataflow with a list of one-off-suppliers
react(Iterator<Supplier<U>>) - Method in class com.aol.simple.react.stream.BaseSimpleReact
Start a reactive dataflow with a list of one-off-suppliers
react(Supplier<U>...) - Method in class com.aol.simple.react.stream.BaseSimpleReact
Start a reactive dataflow with an array of one-off-suppliers
react(Supplier<U>...) - Method in class com.aol.simple.react.stream.lazy.LazyReact
 
react(Collection<Supplier<U>>) - Method in class com.aol.simple.react.stream.lazy.LazyReact
 
react(Stream<Supplier<U>>) - Method in class com.aol.simple.react.stream.lazy.LazyReact
 
react(Iterator<Supplier<U>>) - Method in class com.aol.simple.react.stream.lazy.LazyReact
 
react(Supplier<U>...) - Method in class com.aol.simple.react.stream.simple.SimpleReact
Start a reactive dataflow with an array of one-off-suppliers
react(Supplier<T>) - Static method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
Create a 'free threaded' asynchronous stream that runs on a single thread (not current) The supplier will be executed asyncrhonously, subsequent tasks will be executed synchronously unless the async() operator is invoked.
react(Supplier<T>...) - Static method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
Create a 'free threaded' asynchronous stream that runs on a single thread (not current) The supplier will be executed asyncrhonously, subsequent tasks will be executed synchronously unless the async() operator is invoked.
react(Supplier<T>) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Create a 'free threaded' asynchronous stream that runs on a single thread (not current) The supplier will be executed asyncrhonously, subsequent tasks will be executed synchronously unless the async() operator is invoked.
react(Supplier<T>...) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Create a 'free threaded' asynchronous stream that runs on a single thread (not current) The supplier will be executed asyncrhonously, subsequent tasks will be executed synchronously unless the async() operator is invoked.
react(Function<REACTOR, T>) - Method in class com.aol.simple.react.threads.ReactPool
 
ReactBuilder - Interface in com.aol.simple.react.stream
 
reactCollection(Collection<Supplier<U>>) - Method in class com.aol.simple.react.stream.simple.SimpleReact
Start a reactive dataflow with a list of one-off-suppliers
reactI(Supplier<U>...) - Method in class com.aol.simple.react.stream.BaseSimpleReact
This internal method has been left protected, so it can be mocked / stubbed as some of the entry points are final
reactI(Supplier<U>...) - Method in class com.aol.simple.react.stream.lazy.LazyReact
 
reactI(Supplier<U>...) - Method in class com.aol.simple.react.stream.simple.SimpleReact
This internal method has been left protected, so it can be mocked / stubbed as some of the entry points are final
reactInfinitely(Supplier<U>) - Method in class com.aol.simple.react.stream.lazy.LazyReact
Generate an infinite reactive flow.
reactInfinitelyAsync(Supplier<U>) - Method in class com.aol.simple.react.stream.lazy.LazyReact
Generate an infinite reactive flow.
reactIterable(Iterable<Supplier<T>>) - Method in class com.aol.simple.react.mixins.OptimizedLazyReact
Generate a FutureStream from the specified Iterable of Suppliers.
reactIterable(Iterable<Supplier<U>>) - Method in class com.aol.simple.react.stream.BaseSimpleReact
Start a reactive dataflow with a list of one-off-suppliers
reactIterable(Iterable<Supplier<U>>) - Method in class com.aol.simple.react.stream.lazy.LazyReact
 
reactIterable(Iterable<Supplier<U>>) - Method in class com.aol.simple.react.stream.simple.SimpleReact
Start a reactive dataflow with a list of one-off-suppliers
reactIterator(Iterator<Supplier<U>>) - Method in class com.aol.simple.react.stream.simple.SimpleReact
Start a reactive dataflow with a list of one-off-suppliers
ReactPool<REACTOR extends ReactBuilder> - Class in com.aol.simple.react.threads
Maintain a pool of x-react builders x-react builders (SimpleReact, EagerReact, LazyReact) can be extracted and returned to the pool externally or Streams creating functions can be supplied to the ReactPool which will select an x-react builder, run the stream and return the x-react builder to the pool
reactStream(Stream<Supplier<U>>) - Method in class com.aol.simple.react.stream.simple.SimpleReact
Start a reactive dataflow with a list of one-off-suppliers
recover(Function<Throwable, U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
recover(Class<EX>, Function<EX, U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
reduce(Function<FastFuture, T>, T, BinaryOperator<T>) - Method in class com.aol.simple.react.collectors.lazy.IncrementalReducer
 
reduce(Function<FastFuture, T>, BinaryOperator<T>) - Method in class com.aol.simple.react.collectors.lazy.IncrementalReducer
 
reduce(Function<FastFuture, T>, U, BiFunction<U, ? super T, U>, BinaryOperator<U>) - Method in class com.aol.simple.react.collectors.lazy.IncrementalReducer
 
reduce(BinaryOperator<CompletableFuture<T>>) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Reduce a Stream
reduce(CompletableFuture<T>, BinaryOperator<CompletableFuture<T>>) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
 
reduce(CompletableFuture<U>, BiFunction<CompletableFuture<U>, ? super CompletableFuture<T>, CompletableFuture<U>>, BinaryOperator<CompletableFuture<U>>) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
 
reduce(U, BinaryOperator<U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
reduce(T, BiFunction<T, ? super U, T>, BinaryOperator<T>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
reduce(BinaryOperator<U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
reduce(Monoid<U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
reduce(Stream<Monoid<U>>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
reduce(Iterable<Monoid<U>>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
reduce(BinaryOperator<U>) - Method in interface com.aol.simple.react.stream.traits.LazyStream
 
reduce(U, BinaryOperator<U>) - Method in interface com.aol.simple.react.stream.traits.LazyStream
 
reduce(T, BiFunction<T, ? super U, T>, BinaryOperator<T>) - Method in interface com.aol.simple.react.stream.traits.LazyStream
 
reduceResults(Collection<FastFuture<T>>, Function<FastFuture, T>, T, BinaryOperator<T>) - Method in class com.aol.simple.react.collectors.lazy.IncrementalReducer
 
reduceResults(Collection<FastFuture<T>>, Function<FastFuture, T>, BinaryOperator<T>) - Method in class com.aol.simple.react.collectors.lazy.IncrementalReducer
 
reduceResults(Collection<FastFuture<T>>, Function<FastFuture, T>, U, BiFunction<U, ? super T, U>, BinaryOperator<U>) - Method in class com.aol.simple.react.collectors.lazy.IncrementalReducer
 
register(Object, Adapter<V>) - Static method in class com.aol.simple.react.async.pipes.Pipes
Register a Queue, and get back a listening LazyFutureStream that runs on a single thread (not the calling thread)
registerForCPU(Object, Adapter<V>) - Static method in class com.aol.simple.react.async.pipes.PipesToLazyStreams
Register a Queue, and get back a listening LazyFutureStream optimized for CPU Bound operations Convert the LazyFutureStream to async mode to fan out operations across threads, after the first fan out operation definition it should be converted to sync mode
registerForIO(Object, Adapter<V>) - Static method in class com.aol.simple.react.async.pipes.PipesToLazyStreams
Register a Queue, and get back a listening LazyFutureStream optimized for IO Bound operations
registerLimit(long) - Method in class com.aol.simple.react.async.subscription.AlwaysContinue
 
registerLimit(long) - Method in interface com.aol.simple.react.async.subscription.Continueable
 
registerLimit(long) - Method in class com.aol.simple.react.async.subscription.Subscription
 
registerSkip(long) - Method in class com.aol.simple.react.async.subscription.AlwaysContinue
 
registerSkip(long) - Method in interface com.aol.simple.react.async.subscription.Continueable
 
registerSkip(long) - Method in class com.aol.simple.react.async.subscription.Subscription
 
registerTimeLimit(long) - Method in class com.aol.simple.react.async.subscription.AlwaysContinue
 
registerTimeLimit(long) - Method in interface com.aol.simple.react.async.subscription.Continueable
 
registerTimeLimit(long) - Method in class com.aol.simple.react.async.subscription.Subscription
 
remainingCapacity() - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
remove() - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
remove(Object) - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
removeAll(Collection) - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
removeIf(Predicate) - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
RepeatableStream<T> - Class in com.aol.simple.react.stream.traits
 
RepeatableStream() - Constructor for class com.aol.simple.react.stream.traits.RepeatableStream
 
resolveForCrossTypeFlatMap(Comprehender, SimpleReactStream) - Method in class com.aol.simple.react.monad.SimpleReactStreamComprehender
 
result - Variable in class com.aol.simple.react.async.future.FastFuture.OnComplete
 
retainAll(Collection) - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
retry(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
Will execute this phase on the RetryExecutor (default or user supplied).
retry(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
retry(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
Will execute this phase on the RetryExecutor (default or user supplied).
retry(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Will execute this phase on the RetryExecutor (default or user supplied).
RetryBuilder - Class in com.aol.simple.react
 
RetryBuilder() - Constructor for class com.aol.simple.react.RetryBuilder
 
RetryBuilder.factory - Enum in com.aol.simple.react
 
returnPopulator(LazyReact) - Method in class com.aol.simple.react.stream.lazy.LazyFutureStreamImpl
 
returnPopulator(LazyReact) - Method in interface com.aol.simple.react.stream.traits.LazyToQueue
 
reverse() - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Reverse this Stream, by reversing the order in which the underlying Futures will be processed
reverse() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Reverse a stream.
reverse() - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Reversed, operating on the underlying futures.
rightOuterJoin(Stream<T>, BiPredicate<U, T>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Right outer join 2 streams into one.
run(LazyFutureStream<T>) - Method in interface com.aol.simple.react.mixins.LazyReactive
Convenience method that runs a LazyFutureStream without blocking the current thread
run(LazyStreamWrapper<U>, EmptyCollector<U>) - Method in class com.aol.simple.react.stream.Runner
 
run() - Method in interface com.aol.simple.react.stream.traits.LazyStream
Trigger a lazy stream
run(Collector<U, A, R>) - Method in interface com.aol.simple.react.stream.traits.LazyStream
Trigger a lazy stream and return the results in the Collection created by the collector
runContinuation(Runnable) - Method in interface com.aol.simple.react.stream.traits.LazyStream
 
runContinuations(LazyStreamWrapper, EmptyCollector) - Method in class com.aol.simple.react.stream.Runner
 
Runner<U> - Class in com.aol.simple.react.stream
 
Runner() - Constructor for class com.aol.simple.react.stream.Runner
 
runOn(Executor) - Method in interface com.aol.simple.react.stream.traits.LazyStream
Trigger a lazy stream as a task on the provided Executor
runOnCurrent() - Method in interface com.aol.simple.react.stream.traits.LazyStream
Trigger a lazy stream
runThread(Runnable) - Method in interface com.aol.simple.react.stream.traits.LazyStream
 

S

safeJoin(FastFuture<T>) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
 
safeJoin(FastFuture<T>) - Method in class com.aol.simple.react.stream.traits.future.operators.OperationsOnFuturesImpl
 
SamplingCollector<T> - Class in com.aol.simple.react.collectors.lazy
Class that allows client code to only collect a sample of results from an Infinite SimpleReact Stream The SamplingCollector won't collect results itself, but hand of control to a consumer that can when Sampling triggered.
SamplingCollector(int, LazyResultConsumer<T>) - Constructor for class com.aol.simple.react.collectors.lazy.SamplingCollector
 
scanLeft(T, BiFunction<T, ? super U, T>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Scan a stream to the left.
scanLeft(Monoid<U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
scanRight(R, BiFunction<? super U, R, R>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Scan a stream to the right.
scanRight(Monoid<U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
self(Consumer<LazyFutureStream<U>>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Give a consumer access to this Stream
self(Consumer<SimpleReactStream<U>>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Give a function access to the current stage of a SimpleReact Stream
SEQUENTIAL - Static variable in class com.aol.simple.react.config.MaxActive
 
sequential() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
sequentialBuilder() - Static method in class com.aol.simple.react.stream.lazy.LazyReact
 
sequentialBuilder() - Static method in class com.aol.simple.react.stream.simple.SimpleReact
 
sequentialCommonBuilder() - Static method in class com.aol.simple.react.stream.lazy.LazyReact
 
sequentialCommonBuilder() - Static method in class com.aol.simple.react.stream.simple.SimpleReact
 
sequentialCurrentBuilder() - Static method in class com.aol.simple.react.stream.lazy.LazyReact
 
SequentialElasticPools - Class in com.aol.simple.react.threads
A ReactPool of each type for sequential Streams
SequentialElasticPools() - Constructor for class com.aol.simple.react.threads.SequentialElasticPools
 
set(T) - Method in class com.aol.simple.react.async.future.FastFuture
 
set(T) - Method in class com.aol.simple.react.async.Signal
Set the current value of this signal
setUseCommon(boolean) - Static method in class com.aol.simple.react.stream.ThreadPools
 
shard(Map<K, Queue<U>>, Function<U, K>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Break a stream into multiple Streams based of some characteristic of the elements of the Stream e.g.
shuffle() - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
 
shuffle(Random) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Shuffle a stream using specified source of randomness // e.g.
shuffle() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Shuffle a stream // e.g.
shuffle(Random) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Shuffle a stream using specified source of randomness // e.g.
Signal<T> - Class in com.aol.simple.react.async
Datastructure that accepts a Stream of data and outputs a Stream of changes
Signal(Adapter<T>, Adapter<T>) - Constructor for class com.aol.simple.react.async.Signal
Construct a new Signal
SimpleReact - Class in com.aol.simple.react.stream.simple
Builder class for FutureStream react methods - submit Suppliers to task executor of methods - build Streams directly from data
SimpleReact() - Constructor for class com.aol.simple.react.stream.simple.SimpleReact
Construct a SimpleReact builder using standard thread pool.
SimpleReact(Executor, RetryExecutor, Boolean) - Constructor for class com.aol.simple.react.stream.simple.SimpleReact
 
SimpleReact(Executor) - Constructor for class com.aol.simple.react.stream.simple.SimpleReact
 
SimpleReact(Executor, RetryExecutor) - Constructor for class com.aol.simple.react.stream.simple.SimpleReact
 
SimpleReact(Executor, RetryExecutor, Executor) - Constructor for class com.aol.simple.react.stream.simple.SimpleReact
 
SimpleReact(Executor, Executor, RetryExecutor, Boolean) - Constructor for class com.aol.simple.react.stream.simple.SimpleReact
 
simpleReact - Static variable in class com.aol.simple.react.threads.ParallelElasticPools
 
simpleReact - Static variable in class com.aol.simple.react.threads.SequentialElasticPools
 
SimpleReactCompletionException - Exception in com.aol.simple.react.exceptions
 
SimpleReactCompletionException(Throwable) - Constructor for exception com.aol.simple.react.exceptions.SimpleReactCompletionException
 
SimpleReactFailedStageException - Exception in com.aol.simple.react.exceptions
 
SimpleReactFailedStageException() - Constructor for exception com.aol.simple.react.exceptions.SimpleReactFailedStageException
 
SimpleReactProcessingException - Exception in com.aol.simple.react.exceptions
 
SimpleReactProcessingException() - Constructor for exception com.aol.simple.react.exceptions.SimpleReactProcessingException
 
SimpleReactProcessingException(String, Throwable, boolean, boolean) - Constructor for exception com.aol.simple.react.exceptions.SimpleReactProcessingException
 
SimpleReactProcessingException(String, Throwable) - Constructor for exception com.aol.simple.react.exceptions.SimpleReactProcessingException
 
SimpleReactProcessingException(String) - Constructor for exception com.aol.simple.react.exceptions.SimpleReactProcessingException
 
SimpleReactProcessingException(Throwable) - Constructor for exception com.aol.simple.react.exceptions.SimpleReactProcessingException
 
simpleReactStream(CompletableFuture<T>) - Static method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
Create a 'free threaded' asynchronous stream that runs on the supplied CompletableFutures executor service (unless async operator invoked , in which it will switch to the common 'free' thread executor) Subsequent tasks will be executed synchronously unless the async() operator is invoked.
simpleReactStream(CompletableFuture<T>...) - Static method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
Create a 'free threaded' asynchronous stream that runs on a single thread (not current) The supplier will be executed asyncrhonously, subsequent tasks will be executed synchronously unless the async() operator is invoked.
simpleReactStream(Stream<T>) - Static method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
Wrap a Stream into a SimpleReactStream.
simpleReactStream(Iterator<T>) - Static method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
Wrap an Iterator into a FutureStream.
SimpleReactStream<U> - Interface in com.aol.simple.react.stream.traits
 
SimpleReactStreamComprehender - Class in com.aol.simple.react.monad
Cyclops Monad Comprehender for SimpleReactStreams
SimpleReactStreamComprehender() - Constructor for class com.aol.simple.react.monad.SimpleReactStreamComprehender
 
simpleReactStreamFrom(Stream<CompletableFuture<T>>) - Static method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
Create a 'free threaded' asynchronous stream that runs on the supplied CompletableFutures executor service (unless async operator invoked , in which it will switch to the common 'free' thread executor) Subsequent tasks will be executed synchronously unless the async() operator is invoked.
simpleReactStreamFromIterable(Iterable<T>) - Static method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
Wrap an Iterable into a FutureStream.
SimpleReactStreamImpl<U> - Class in com.aol.simple.react.stream.simple
 
SimpleReactStreamImpl(SimpleReact, Stream<CompletableFuture<U>>) - Constructor for class com.aol.simple.react.stream.simple.SimpleReactStreamImpl
 
SimpleTimer - Class in com.aol.simple.react.util
Simple Timer class that returns elapsed milliseconds since construction
SimpleTimer() - Constructor for class com.aol.simple.react.util.SimpleTimer
 
SingleContinuation - Class in com.aol.simple.react.async
 
SingleContinuation(Queue<?>) - Constructor for class com.aol.simple.react.async.SingleContinuation
 
singleWriterboundedNonBlockingQueue(int) - Static method in class com.aol.simple.react.async.factories.QueueFactories
Creates an async.Queue backed by an Agrona OneToOneConcurrentArrayQueue bounded by specified queueSize Wait strategy used is NoWaitRetry by default for both Consumers and Producers (both Consumers and Producers will repeatedly retry until successful).
size() - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
size() - Method in class com.aol.simple.react.async.Queue
 
skip(long) - Method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
 
skip(long) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
assertThat(of(1,2,3,4,5).actOnFutures().skip(2).collect(Collectors.toList()).size(),is(3));
skip(long) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
skip(long, TimeUnit) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
skip(long) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
In contast to EagerFutureStream#skip skipFutures will skip the first n entries of the underlying Stream of Futures.
skipLast(int) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Skip the last num of elements from this Stream
skipLast(int) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
skipUntil(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Returns a stream with all elements skipped for which a predicate evaluates to false.
skipUntil(SimpleReactStream<T>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Return a Stream with the same values as this Stream, but with all values omitted until the provided stream starts emitting values.
skipWhile(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Returns a stream with all elements skipped for which a predicate evaluates to true.
slice(long, long) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Returns a limited interval from a given Stream.
slice(long, long) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
slice(long, long) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Returns a limited interval from a given Stream.
sliding(int) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Create a sliding view over this Sequence
sliding(int, int) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Create a sliding view over this Sequence
sliding(int) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Create a sliding view over this Stream
sliding(int, int) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Create a sliding view over this Stream
sliding(Stream<T>, int, int) - Static method in class com.aol.simple.react.stream.traits.operators.SlidingWindow
 
SlidingWindow - Class in com.aol.simple.react.stream.traits.operators
 
SlidingWindow() - Constructor for class com.aol.simple.react.stream.traits.operators.SlidingWindow
 
sorted() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
sorted(Comparator<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
sorted(Function<? super U, ? extends R>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
SpinWait<T> - Class in com.aol.simple.react.async.wait
Repeatedly retry to take or offer element to Queue if full or data unavailable, with a wait of 1 nano second between retries
SpinWait() - Constructor for class com.aol.simple.react.async.wait.SpinWait
 
splitAt(int) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Split at supplied location
splitAt(int) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
splitAt(long) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Split a stream at a given position.
splitAtHead() - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Split a Stream at it's head (similar to headAndTail)
splitBy(Predicate<U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
spliterator() - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
spliterator() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
splitSequenceAtHead() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
StageWithResults<RS,U> - Class in com.aol.simple.react.stream
 
StageWithResults(ConfigurableStream<U, Object>, RS) - Constructor for class com.aol.simple.react.stream.StageWithResults
 
startsWith(Iterable<U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
startsWith(Iterator<U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
Status<T> - Class in com.aol.simple.react.stream
Class that returned to blocking predicates for short circuiting result collection
Status() - Constructor for class com.aol.simple.react.stream.Status
 
stream() - Method in interface com.aol.simple.react.async.Adapter
 
stream(Continueable) - Method in interface com.aol.simple.react.async.Adapter
 
stream() - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
stream(Object) - Static method in class com.aol.simple.react.async.pipes.PipesToLazyStreams
 
stream() - Method in class com.aol.simple.react.async.Queue
 
stream(Continueable) - Method in class com.aol.simple.react.async.Queue
 
stream() - Method in class com.aol.simple.react.async.Topic
Generating a stream will register the Stream as a subscriber to this topic.
stream(Continueable) - Method in class com.aol.simple.react.async.Topic
 
stream - Variable in class com.aol.simple.react.reactivestreams.FutureStreamSubscriber
 
stream() - Method in class com.aol.simple.react.reactivestreams.FutureStreamSubscriber
 
stream - Variable in class com.aol.simple.react.reactivestreams.JDKReactiveStreamsSubscriber
 
stream() - Method in class com.aol.simple.react.reactivestreams.JDKReactiveStreamsSubscriber
 
stream(Function<Stream<CompletableFuture>, Stream<CompletableFuture>>) - Method in class com.aol.simple.react.stream.EagerStreamWrapper
 
stream() - Method in class com.aol.simple.react.stream.EagerStreamWrapper
 
stream() - Method in class com.aol.simple.react.stream.LazyStreamWrapper
 
stream() - Method in interface com.aol.simple.react.stream.StreamWrapper
 
stream() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
stream(Iterator<U>) - Static method in class com.aol.simple.react.stream.traits.operators.SlidingWindow
 
stream() - Method in class com.aol.simple.react.stream.traits.RepeatableStream
 
streamBatch(Continueable, Function<BiFunction<Long, TimeUnit, T>, Supplier<Collection<T>>>) - Method in class com.aol.simple.react.async.Queue
 
streamBatchNoTimeout(Continueable, Function<Supplier<T>, Supplier<Collection<T>>>) - Method in class com.aol.simple.react.async.Queue
 
streamCompletableFutures() - Method in interface com.aol.simple.react.async.Adapter
 
streamCompletableFutures() - Method in class com.aol.simple.react.async.Queue
 
streamCompletableFutures() - Method in class com.aol.simple.react.async.Topic
Generating a streamCompletableFutures will register the Stream as a subscriber to this topic.
streamCompletableFutures() - Method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
 
streamCompletableFutures() - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
 
streamCompletableFutures() - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
streamControl(Continueable, Function<Supplier<T>, Supplier<T>>) - Method in class com.aol.simple.react.async.Queue
 
streamControlFutures(Continueable, Function<Supplier<T>, CompletableFuture<T>>) - Method in class com.aol.simple.react.async.Queue
 
StreamCopier - Class in com.aol.simple.react.stream.traits.operators
 
StreamCopier() - Constructor for class com.aol.simple.react.stream.traits.operators.StreamCopier
 
streamCPUBound(Object) - Static method in class com.aol.simple.react.async.pipes.PipesToLazyStreams
 
streamIOBound(Object) - Static method in class com.aol.simple.react.async.pipes.PipesToLazyStreams
 
StreamOfContinuations - Class in com.aol.simple.react.async
 
StreamOfContinuations(Queue<?>) - Constructor for class com.aol.simple.react.async.StreamOfContinuations
 
StreamWrapper<U> - Interface in com.aol.simple.react.stream
 
submit(Function<RS, R>) - Method in class com.aol.simple.react.stream.StageWithResults
This method allows the SimpleReact Executor to be reused by JDK parallel streams.
submit(Callable<T>) - Method in class com.aol.simple.react.stream.StageWithResults
This method allows the SimpleReact Executor to be reused by JDK parallel streams
subscribe(Subscriber<? super T>) - Method in interface com.aol.simple.react.reactivestreams.FutureStreamAsyncPublisher
 
subscribe(Subscriber<? super T>) - Method in interface com.aol.simple.react.reactivestreams.FutureStreamSynchronousPublisher
 
subscribe(Subscriber<? super T>) - Method in class com.aol.simple.react.reactivestreams.JDKReactiveStreamsPublisher
 
subscribe(Stream<T>, Subscriber<? super T>) - Method in class com.aol.simple.react.reactivestreams.sequenceM.PublisherForCyclops
 
subscribe() - Method in class com.aol.simple.react.reactivestreams.sequenceM.SubscriberForCyclops
 
subscribe(Subscriber<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
subscribeAsync(Subscriber<? super T>) - Method in interface com.aol.simple.react.reactivestreams.FutureStreamAsyncPublisher
 
subscribeOn(Subscriber<? super T>, Executor) - Method in interface com.aol.simple.react.reactivestreams.FutureStreamAsyncPublisher
 
SubscriberForCyclops<T> - Class in com.aol.simple.react.reactivestreams.sequenceM
 
SubscriberForCyclops() - Constructor for class com.aol.simple.react.reactivestreams.sequenceM.SubscriberForCyclops
 
subscribeSync(Subscriber<? super T>) - Method in interface com.aol.simple.react.reactivestreams.FutureStreamSynchronousPublisher
 
subscribeTo(Object, Subscriber<T>, Executor) - Static method in class com.aol.simple.react.async.pipes.Pipes
 
Subscription - Class in com.aol.simple.react.async.subscription
 
Subscription() - Constructor for class com.aol.simple.react.async.subscription.Subscription
 
switchOnNextValue(Stream<LazyFutureStream>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Merges this stream and the supplied Streams into a single Stream where the next value is the next returned across any of the involved Streams.
switchToCPU(LazyFutureStream<T>) - Method in interface com.aol.simple.react.mixins.LazyReactive
Switch LazyFutureStream into execution mode suitable for CPU bound execution (reuse cpuReactors task executor)
switchToIO(LazyFutureStream<T>) - Method in interface com.aol.simple.react.mixins.LazyReactive
Switch LazyFutureStream into execution mode suitable for IO (reuse ioReactors task executor)
sync(Function<LazyReact, LazyFutureStream<T>>) - Method in interface com.aol.simple.react.mixins.LazyReactive
Generate a sequentially executing single-threaded a LazyFutureStream that executes all tasks directly without involving a task executor between each stage (unless async operator invoked).
sync() - Method in class com.aol.simple.react.stream.lazy.LazyReact
Start any created Streams in syncrhonous mode - that is tasks will be executed on the calling thread
sync() - Method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
 
sync() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
sync() - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
synchronousQueue() - Static method in class com.aol.simple.react.async.factories.QueueFactories
 
syncrhonousPool() - Static method in class com.aol.simple.react.threads.ReactPool
 

T

take() - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
take(WaitStrategy.Takeable<T>) - Method in class com.aol.simple.react.async.wait.DirectWaitStrategy
 
take(WaitStrategy.Takeable<T>) - Method in class com.aol.simple.react.async.wait.ExponentialBackofWaitStrategy
 
take(WaitStrategy.Takeable<T>) - Method in class com.aol.simple.react.async.wait.NoWaitRetry
 
take(WaitStrategy.Takeable<T>) - Method in class com.aol.simple.react.async.wait.SpinWait
 
take(WaitStrategy.Takeable<T>) - Method in interface com.aol.simple.react.async.wait.WaitStrategy
 
take() - Method in interface com.aol.simple.react.async.wait.WaitStrategy.Takeable
 
take(WaitStrategy.Takeable<T>) - Method in class com.aol.simple.react.async.wait.YieldWait
 
takeUntil(SimpleReactStream<T>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Return a Stream with the same values, but will stop emitting values once the provided Stream starts to emit values.
then(Function<U, R>, Executor) - Method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
 
then(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
React then Unlike 'with' this method is fluent, and returns another Stage Builder that can represent the next stage in the dataflow.
then(Function<U, R>, Executor) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
then(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
then(Function<U, R>, Executor) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
 
then(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
React then Unlike 'with' this method is fluent, and returns another Stage Builder that can represent the next stage in the dataflow.
then(Function<U, R>, Executor) - Method in interface com.aol.simple.react.stream.traits.LazyToQueue
 
then(Function<U, R>, Executor) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
then(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
React then Unlike 'with' this method is fluent, and returns another Stage Builder that can represent the next stage in the dataflow.
thenApply(Function<T, R>) - Method in class com.aol.simple.react.async.future.ExecutionPipeline
 
thenApply(Function<T, R>) - Method in class com.aol.simple.react.async.future.PipelineBuilder
 
thenApplyAsync(Function<T, R>, Executor) - Method in class com.aol.simple.react.async.future.ExecutionPipeline
 
thenApplyAsync(Function<T, R>, Executor) - Method in class com.aol.simple.react.async.future.PipelineBuilder
 
thenCombine(BiFunction<T, T, R>) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Combines every pair of values (any odd remaining value will be dropped)
thenCompose(Function<T, CompletableFuture<R>>) - Method in class com.aol.simple.react.async.future.ExecutionPipeline
 
thenCompose(Function<T, CompletableFuture<R>>) - Method in class com.aol.simple.react.async.future.PipelineBuilder
 
thenComposeAsync(Function<Object, CompletableFuture<?>>, Executor) - Method in class com.aol.simple.react.async.future.ExecutionPipeline
 
thenComposeAsync(Function<T, CompletableFuture<R>>, Executor) - Method in class com.aol.simple.react.async.future.PipelineBuilder
 
thenSync(Function<U, R>) - Method in class com.aol.simple.react.stream.simple.SimpleReactStreamImpl
 
thenSync(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
 
thenSync(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.EagerToQueue
 
thenSync(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
thenSync(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
 
thenSync(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.LazyToQueue
 
thenSync(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
ThreadPools - Class in com.aol.simple.react.stream
 
ThreadPools() - Constructor for class com.aol.simple.react.stream.ThreadPools
 
ThreadPools.ExecutionMode - Enum in com.aol.simple.react.stream
 
throwSoftenedException(Throwable) - Method in class com.aol.simple.react.exceptions.ExceptionSoftener
 
ThrowsSoftened - Annotation Type in com.aol.simple.react.exceptions
 
timeLimit() - Method in class com.aol.simple.react.async.subscription.AlwaysContinue
 
timeLimit() - Method in interface com.aol.simple.react.async.subscription.Continueable
 
timeLimit() - Method in class com.aol.simple.react.async.subscription.Subscription
 
toArray() - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
toArray(Object[]) - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
toArray() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
toArray(IntFunction<A[]>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
toBufferingCopier(Iterator<A>, int) - Static method in class com.aol.simple.react.stream.traits.operators.StreamCopier
 
toBufferingDuplicator(Iterator<A>) - Static method in class com.aol.simple.react.stream.traits.operators.StreamCopier
 
toBufferingDuplicator(Iterator<A>, long) - Static method in class com.aol.simple.react.stream.traits.operators.StreamCopier
 
toCollection(Supplier<C>) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Collect a Stream into a Collection
toCollection(Supplier<C>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
toCompletableFuture() - Method in class com.aol.simple.react.async.future.FastFuture
 
toCompletableFuture() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
toConcurrentLazyCollection() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
toConcurrentLazyStreamable() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
toFinalPipeline() - Method in class com.aol.simple.react.async.future.ExecutionPipeline
 
toLazyCollection() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
toList() - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Collect a Stream into a List.
toList() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
toOptional() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
Topic<T> - Class in com.aol.simple.react.async
A class that can accept input streams and generate output streams where data sent in the Topic is guaranteed to be provided to all Topic subsribers
Topic() - Constructor for class com.aol.simple.react.async.Topic
Construct a new Topic
Topic(Queue<T>) - Constructor for class com.aol.simple.react.async.Topic
Construct a Topic using the Queue provided
topicBackedSignal() - Static method in class com.aol.simple.react.async.Signal
 
toQueue() - Method in interface com.aol.simple.react.reactivestreams.FutureStreamAsyncPublisher
 
toQueue() - Method in interface com.aol.simple.react.reactivestreams.FutureStreamSynchronousPublisher
 
toQueue() - Method in class com.aol.simple.react.stream.simple.SimpleReactStreamImpl
 
toQueue() - Method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
 
toQueue() - Method in interface com.aol.simple.react.stream.traits.EagerToQueue
Convert the current Stream to a SimpleReact Queue
toQueue(Function<Queue, Queue>) - Method in interface com.aol.simple.react.stream.traits.EagerToQueue
 
toQueue(Map<K, Queue<U>>, Function<U, K>) - Method in interface com.aol.simple.react.stream.traits.EagerToQueue
 
toQueue() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
toQueue() - Method in interface com.aol.simple.react.stream.traits.LazyToQueue
Convert the current Stream to a simple-react Queue
toQueue(Function<Queue, Queue>) - Method in interface com.aol.simple.react.stream.traits.LazyToQueue
 
toQueue(Map<K, Queue<U>>, Function<U, K>) - Method in interface com.aol.simple.react.stream.traits.LazyToQueue
 
ToQueue<U> - Interface in com.aol.simple.react.stream.traits
interface that defines the conversion of an object to a queue
toQueue() - Method in interface com.aol.simple.react.stream.traits.ToQueue
 
toQueue(Map<K, Queue<U>>, Function<U, K>) - Method in interface com.aol.simple.react.stream.traits.ToQueue
Sharded data in queues
toQueue(Function<Queue, Queue>) - Method in interface com.aol.simple.react.stream.traits.ToQueue
Method to create a Queue that can be modified by supplied funciton
toSet() - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Collect a Stream into a Set.
toSet() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
toStream() - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Convert this FutureStream to a Stream of CompletableFutures
toStream() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
toStreamable() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
toString() - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
triplicate() - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Triplicates a Stream.
triplicate() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
tryAdvance(Consumer<? super T>) - Method in class com.aol.simple.react.async.ClosingSpliterator
 
tryAdvance(Consumer<? super T>) - Method in class com.aol.simple.react.stream.InfiniteClosingSpliterator
 
tryAdvance(Consumer<? super T>) - Method in class com.aol.simple.react.stream.InfiniteClosingSpliteratorFromIterator
 
trySplit() - Method in class com.aol.simple.react.async.ClosingSpliterator
 
trySplit() - Method in class com.aol.simple.react.stream.InfiniteClosingSpliterator
 
trySplit() - Method in class com.aol.simple.react.stream.InfiniteClosingSpliteratorFromIterator
 

U

unboundedNonBlockingQueue() - Static method in class com.aol.simple.react.async.factories.QueueFactories
Creates an async.Queue backed by a JDK Wait Free unbounded ConcurrentLinkedQueue Wait strategy used is NoWaitRetry by default for both Consumers and Producers (both Consumers and Producers will repeatedly retry until successful).
unboundedPool(Collection<REACTOR>) - Static method in class com.aol.simple.react.threads.ReactPool
If all REACTORs are in use calling react will block.
unboundedQueue() - Static method in class com.aol.simple.react.async.factories.QueueFactories
 
unboundedWaitFree() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
This is the default setting, internal queues are backed by a ConcurrentLinkedQueue This operator will return the next stage to using this Queue type if it has been changed
unordered() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
unwrap() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
START SEQUENCEM

V

Val<T> - Class in com.aol.simple.react.stream.traits
 
Val() - Constructor for class com.aol.simple.react.stream.traits.Val
 
valueOf(String) - Static method in enum com.aol.simple.react.exceptions.ExceptionSoftener.singleton
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.aol.simple.react.RetryBuilder.factory
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.aol.simple.react.stream.ThreadPools.ExecutionMode
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.aol.simple.react.exceptions.ExceptionSoftener.singleton
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.aol.simple.react.RetryBuilder.factory
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.aol.simple.react.stream.ThreadPools.ExecutionMode
Returns an array containing the constants of this enum type, in the order they are declared.

W

WaitStrategy<T> - Interface in com.aol.simple.react.async.wait
 
WaitStrategy.Offerable - Interface in com.aol.simple.react.async.wait
 
WaitStrategy.Takeable<T> - Interface in com.aol.simple.react.async.wait
 
whenComplete(BiConsumer<T, X>) - Method in class com.aol.simple.react.async.future.ExecutionPipeline
 
whenComplete(BiConsumer<T, X>) - Method in class com.aol.simple.react.async.future.PipelineBuilder
 
windowBySizeAndTime(int, long, TimeUnit) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
windowByTime(long, TimeUnit) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
windowStatefullyWhile(BiPredicate<Streamable<U>, U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
windowUntil(Predicate<U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
windowWhile(Predicate<U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
with(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
React with Asynchronously apply the function supplied to the currently active event tasks in the dataflow.
withAsync(boolean) - Method in class com.aol.simple.react.stream.lazy.LazyFutureStreamImpl
 
withAsync(boolean) - Method in class com.aol.simple.react.stream.simple.SimpleReactStreamImpl
 
withAsync(boolean) - Method in interface com.aol.simple.react.stream.traits.ConfigurableStream
 
withAsync(boolean) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
withAsync(boolean) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
 
withAsync(boolean) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
withErrorHandler(Optional<Consumer<Throwable>>) - Method in interface com.aol.simple.react.stream.traits.ConfigurableStream
 
withErrorHandler(Optional<Consumer<Throwable>>) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
 
withErrorHandler(Optional<Consumer<Throwable>>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
withLastActive(LazyStreamWrapper) - Method in class com.aol.simple.react.stream.lazy.LazyFutureStreamImpl
 
withLastActive(LazyStreamWrapper<T>) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
 
withLastActive(LazyStreamWrapper<T>) - Method in class com.aol.simple.react.stream.traits.future.operators.OperationsOnFuturesImpl
 
withLastActive(LazyStreamWrapper<R>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
withLastActive(LazyStreamWrapper<R>) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
 
withLastActive(EagerStreamWrapper) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
withLatest(SimpleReactStream<T2>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
withLazyCollector(Supplier<LazyResultConsumer<U>>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
withNewStream(Stream<CompletableFuture>, SimpleReact) - Method in class com.aol.simple.react.stream.EagerStreamWrapper
 
withNewStream(Stream<R>, LazyReact) - Method in class com.aol.simple.react.stream.LazyStreamWrapper
 
withNewStreamFutures(Stream<R>) - Method in class com.aol.simple.react.stream.LazyStreamWrapper
 
withParallelReduction(ParallelReductionConfig) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
END SEQUENCEM
withPublisherExecutor(Executor) - Method in interface com.aol.simple.react.reactivestreams.FutureStreamAsyncPublisher
 
withQueueCopyExecutor(Executor) - Method in class com.aol.simple.react.stream.simple.SimpleReact
 
withQueueFactory(QueueFactory<U>) - Method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
 
withQueueFactory(QueueFactory<T>) - Method in interface com.aol.simple.react.stream.traits.ConfigurableStream
 
withQueueFactory(QueueFactory<U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
withQueueFactory(QueueFactory<U>) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
 
withQueueFactory(QueueFactory<U>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
withResults(Collection<FastFuture<T>>) - Method in class com.aol.simple.react.collectors.lazy.EmptyCollector
 
withResults(Collection<FastFuture<T>>) - Method in interface com.aol.simple.react.collectors.lazy.LazyResultConsumer
Used to generate a new instance for result collection - populates the supplied Collection
withResults(Collection<FastFuture<T>>) - Method in class com.aol.simple.react.collectors.lazy.SamplingCollector
 
withRetrier(RetryExecutor) - Method in class com.aol.simple.react.stream.lazy.LazyFutureStreamImpl
 
withRetrier(RetryExecutor) - Method in class com.aol.simple.react.stream.simple.SimpleReactStreamImpl
 
withRetrier(RetryExecutor) - Method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
 
withRetrier(RetryExecutor) - Method in interface com.aol.simple.react.stream.traits.ConfigurableStream
 
withRetrier(RetryExecutor) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
withRetrier(RetryExecutor) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
 
withRetrier(RetryExecutor) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
withStream(Stream) - Method in class com.aol.simple.react.stream.LazyStreamWrapper
 
withSubscription(Continueable) - Method in interface com.aol.simple.react.stream.traits.BaseSimpleReactStream
 
withSubscription(Continueable) - Method in interface com.aol.simple.react.stream.traits.ConfigurableStream
 
withSubscription(Continueable) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
withSubscription(Continueable) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
 
withSubscription(Continueable) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
withTaskExecutor(Executor) - Method in class com.aol.simple.react.stream.lazy.LazyFutureStreamImpl
 
withTaskExecutor(Executor) - Method in class com.aol.simple.react.stream.simple.SimpleReactStreamImpl
 
withTaskExecutor(Executor) - Method in interface com.aol.simple.react.stream.traits.ConfigurableStream
 
withTaskExecutor(Executor) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
withTaskExecutor(Executor) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
 
withTaskExecutor(Executor) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 

X

xMatch(int, Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
xOf(int, Runnable, FastFuture...) - Static method in class com.aol.simple.react.async.future.FastFuture
 
xPer(int, long, TimeUnit) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Allows x (specified number of) emissions with a time period before stopping emmissions until specified time has elapsed since last emission

Y

YieldWait<T> - Class in com.aol.simple.react.async.wait
 
YieldWait() - Constructor for class com.aol.simple.react.async.wait.YieldWait
 

Z

zip(Stream<R>) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Zip two Streams.
zip(Seq<T>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Zip two streams into one.
zip(Seq<T>, BiFunction<U, T, R>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Zip two streams into one using a BiFunction to produce resulting values.
zip(Stream<R>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Zip two Streams, zipping against the underlying futures of this stream
zip(SimpleReactStream<R>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Zip two Streams, zipping against the underlying futures of both Streams Placeholders (Futures) will be populated immediately in the new zipped Stream and results will be populated asyncrhonously
zip3(Stream<? extends S>, Stream<? extends U>) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
zip 3 Streams into one
zip3(Stream<? extends S>, Stream<? extends R>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
zip3Lfs(LazyFutureStream<? extends S>, LazyFutureStream<? extends U>) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Zip 3 LazyFutureStreams based on the order of the data in the underlying Futures
zip4(Stream<T2>, Stream<T3>, Stream<T4>) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
zip 4 Streams into 1
zip4(Stream<T2>, Stream<T3>, Stream<T4>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
zip4Lfs(LazyFutureStream<T2>, LazyFutureStream<T3>, LazyFutureStream<T4>) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Zip 4 LazyFutureStreams into 1
zipAnyM(AnyM<? extends S>, BiFunction<? super U, ? super S, ? extends R>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
zipLfs(LazyFutureStream<R>) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Zip two LazyFutureStreams by combining the underlying Futures
zipLfs(LazyFutureStream<T2>, BiFunction<CompletableFuture<T>, CompletableFuture<T2>, CompletableFuture<R>>) - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Zip two LazyFutureStreams using the provided combiner
zipSequence(SequenceM<? extends S>, BiFunction<? super U, ? super S, ? extends R>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
zipStream(Stream<R>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
zipStream(BaseStream<? extends S, ? extends BaseStream<? extends S, ?>>, BiFunction<? super U, ? super S, ? extends R>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
zipWithIndex() - Method in interface com.aol.simple.react.stream.traits.future.operators.OperationsOnFutures
Add an index to the current Stream
zipWithIndex() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Zip a Stream with a corresponding Stream of indexes.
zipWithIndex() - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Zip this Stream with an index, but Zip based on the underlying tasks, not completed results.
A B C D E F G H I J L M N O P Q R S T U V W X Y Z 
Skip navigation links