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 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(CompletableFuture) - Method in class com.aol.simple.react.capacity.monitor.DoNothingMonitor
 
accept(CompletableFuture) - Method in class com.aol.simple.react.capacity.monitor.LimitingMonitor
 
accept(CompletableFuture) - Method in class com.aol.simple.react.capacity.monitor.SamplingMonitor
 
accept(CompletableFuture<T>) - Method in class com.aol.simple.react.collectors.lazy.BatchingCollector
 
accept(CompletableFuture<T>) - Method in class com.aol.simple.react.collectors.lazy.EmptyCollector
 
accept(CompletableFuture<T>) - Method in class com.aol.simple.react.collectors.lazy.SamplingCollector
 
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(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(U, Queue<U>) - Method in interface com.aol.simple.react.stream.traits.LazyToQueue
 
addQueue(Queue) - Method in class com.aol.simple.react.async.AlwaysContinue
 
addQueue(Queue) - Method in interface com.aol.simple.react.async.Continueable
 
addQueue(Queue) - Method in class com.aol.simple.react.async.Subscription
 
allMatch(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
allOf(Collector, Function<T, R>) - Method in class com.aol.simple.react.stream.simple.SimpleReactStreamImpl
 
allOf(Function<List<T>, R>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
allOf(Collector, Function<T, R>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
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.FutureStream
 
allOf(Function<List<T>, R>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
allOf(Function<List<T>, R>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
allOf(Collector, Function<T, R>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
allOf(Collector, Function<T, R>) - Method in interface com.aol.simple.react.stream.traits.LazyToQueue
 
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
 
AlwaysContinue() - Constructor for class com.aol.simple.react.async.AlwaysContinue
 
anyMatch(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
anyOf(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
anyOf(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
anyOf(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
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.
assureSimpleReactException(Throwable) - Static method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
async() - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
async() - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
async() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
async() - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 

B

BaseLazySimpleReact - Class in com.aol.simple.react.stream
 
BaseLazySimpleReact() - Constructor for class com.aol.simple.react.stream.BaseLazySimpleReact
 
BaseSimpleReact - Class in com.aol.simple.react.stream
 
BaseSimpleReact() - Constructor for class com.aol.simple.react.stream.BaseSimpleReact
 
batch(Function<Supplier<U>, Supplier<Collection<U>>>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Batch elements into a Stream of collections with user defined function
batch(Function<Supplier<U>, Supplier<Collection<U>>>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
Batch elements into a Stream of collections with user defined function
batch(Function<Supplier<U>, Supplier<Collection<U>>>) - 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.EagerFutureStream
Batch the elements in this stream into Lists of specified size
batchBySize(int, Supplier<Collection<U>>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Batch the elements in this stream into Collections of specified size The type of Collection is determined by the specified supplier
batchBySize(int) - Method in interface com.aol.simple.react.stream.traits.FutureStream
Batch the elements in this stream into Lists of specified size
batchBySize(int, Supplier<Collection<U>>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
Batch the elements in this stream into Collections of specified size The type of Collection is determined by the specified supplier
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<Collection<U>>) - 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
batchByTime(long, TimeUnit) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Organise elements in a Stream into a Collections based on the time period they pass through this stage
batchByTime(long, TimeUnit, Supplier<Collection<U>>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Organise elements in a Stream into a Collections based on the time period they pass through this stage
batchByTime(long, TimeUnit) - Method in interface com.aol.simple.react.stream.traits.FutureStream
Organise elements in a Stream into a Collections based on the time period they pass through this stage
batchByTime(long, TimeUnit, Supplier<Collection<U>>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
Organise elements in a Stream into a Collections based on the time period they pass through this stage
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<Collection<U>>) - 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
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
 
BatchingCollector(BlockingStream<T>) - Constructor for class com.aol.simple.react.collectors.lazy.BatchingCollector
Batching Collector with default Max Active settings
bind(SimpleReactStream<U>, Function<U, SimpleReactStream<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() - Method in interface com.aol.simple.react.stream.traits.BlockingStream
React and block
block(Collector) - Method in interface com.aol.simple.react.stream.traits.BlockingStream
 
block(Predicate<Status>) - Method in interface com.aol.simple.react.stream.traits.BlockingStream
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.BlockingStream
 
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.QueueFactories
 
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.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.QueueFactory
 

C

cancel() - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Cancel the CompletableFutures in this stage of the stream and the initial phase
cancel() - Method in interface com.aol.simple.react.stream.traits.FutureStream
Cancel the CompletableFutures in this stage of the stream
cancelOriginal() - Method in class com.aol.simple.react.stream.eager.EagerFutureStreamImpl
 
cancelOriginal() - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Cancel the original tasks that populated the EagerFuturestream
capture(Consumer<? extends Throwable>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
capture(Consumer<? extends Throwable>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
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.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.EagerFutureStream
 
cast(Class<U>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
cast(FutureStream<T>, Class<U>) - Static method in interface com.aol.simple.react.stream.traits.FutureStream
Cast all elements in a stream to a given type, possibly throwing a ClassCastException.
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.FutureStream
 
chunkSinceLastRead() - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
chunkSinceLastRead() - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
chunkSinceLastRead() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
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 interface com.aol.simple.react.stream.traits.FutureStream
 
close(Iterator) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
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.AlwaysContinue
 
closeAll() - Method in class com.aol.simple.react.async.AlwaysContinue
 
closeAll(Queue) - Method in interface com.aol.simple.react.async.Continueable
 
closeAll() - Method in interface com.aol.simple.react.async.Continueable
 
closeAll(Queue) - Method in class com.aol.simple.react.async.Subscription
 
closeAll() - Method in class com.aol.simple.react.async.Subscription
 
closeAll() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
closeAndClear() - Method in class com.aol.simple.react.async.Queue
 
closed() - Method in class com.aol.simple.react.async.AlwaysContinue
 
closed() - Method in interface com.aol.simple.react.async.Continueable
 
closed() - Method in class com.aol.simple.react.async.Subscription
 
ClosedQueueException() - Constructor for exception com.aol.simple.react.async.Queue.ClosedQueueException
 
closeOthers(Queue, List<Queue>) - Static method in interface com.aol.simple.react.stream.traits.FutureStream
Close all queues except the active one
closeOthers(FutureStream, List<FutureStream>) - Static method in interface com.aol.simple.react.stream.traits.FutureStream
Close all streams except the active one
closeQueueIfFinished(Queue) - Method in class com.aol.simple.react.async.AlwaysContinue
 
closeQueueIfFinished(Queue) - Method in interface com.aol.simple.react.async.Continueable
 
closeQueueIfFinished(Queue) - Method in class com.aol.simple.react.async.Subscription
 
closeQueueIfFinishedStateless(Queue) - Method in class com.aol.simple.react.async.AlwaysContinue
 
closeQueueIfFinishedStateless(Queue) - Method in interface com.aol.simple.react.async.Continueable
 
closeQueueIfFinishedStateless(Queue) - Method in class com.aol.simple.react.async.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.eager.EagerFutureStreamImpl
 
collect(Collector<? super U, A, R>) - Method in class com.aol.simple.react.stream.lazy.LazyFutureStreamImpl
 
collect(Supplier<R>, BiConsumer<R, ? super U>, BiConsumer<R, R>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
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
 
com.aol.simple.react - package com.aol.simple.react
 
com.aol.simple.react.async - package com.aol.simple.react.async
 
com.aol.simple.react.blockers - package com.aol.simple.react.blockers
 
com.aol.simple.react.capacity.monitor - package com.aol.simple.react.capacity.monitor
 
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.monad - package com.aol.simple.react.monad
 
com.aol.simple.react.stream - package com.aol.simple.react.stream
 
com.aol.simple.react.stream.eager - package com.aol.simple.react.stream.eager
 
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.threads - package com.aol.simple.react.threads
 
com.aol.simple.react.util - package com.aol.simple.react.util
 
combineLatest(FutureStream<T>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Similar to zip and withLatest, except will always take the latest from either Stream (merged with last available from the other).
combineLatest(FutureStream<T>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
Similar to zip and withLatest, except will always take the latest from either Stream (merged with last available from the other).
combineLatest(FutureStream<T1>, FutureStream<T2>) - Static method in interface com.aol.simple.react.stream.traits.FutureStream
Zip two streams into one.
combineLatest(FutureStream<T1>, FutureStream<T2>, BiFunction<T1, T2, R>) - Static method in interface com.aol.simple.react.stream.traits.FutureStream
Zip two streams into one using a BiFunction to produce resulting.
combineLatest(FutureStream<T>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Similar to zip and withLatest, except will always take the latest from either Stream (merged with last available from the other).
concat(Stream<U>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Concatenate two streams.
concat(SimpleReactStream<U>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Concatenate two streams.
concat(U) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Concatenate two streams.
concat(U...) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Concatenate two streams.
concat(Stream<U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Concatenate two streams.
ConfigurableStream<T> - Interface in com.aol.simple.react.stream.traits
 
ConfigurableStream.SimpleReactConfigurableStream<U> - Interface in com.aol.simple.react.stream.traits
 
construct(Stream, List<CompletableFuture>) - Method in class com.aol.simple.react.stream.BaseSimpleReact
 
construct(Stream, List<CompletableFuture>) - Method in class com.aol.simple.react.stream.eager.EagerReact
 
construct(Stream, List<CompletableFuture>) - Method in class com.aol.simple.react.stream.lazy.LazyReact
 
construct(Stream, List<CompletableFuture>) - Method in class com.aol.simple.react.stream.simple.SimpleReact
 
Continuation - Class in com.aol.simple.react.stream.traits
 
Continuation() - Constructor for class com.aol.simple.react.stream.traits.Continuation
 
Continueable - Interface in com.aol.simple.react.async
 
control(Function<Supplier<U>, Supplier<U>>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Allows clients to control the emission of data for the next phase of the Stream.
control(Function<Supplier<U>, Supplier<U>>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
Allows clients to control the emission of data for the next phase of the Stream.
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.
convertToEagerStream() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Convert between an Lazy and Eager future stream, can be used to take advantages of each approach during a single Stream
convertToLazyStream() - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Convert between an Eager and Lazy future stream, can be used to take advantages of each approach during a single Stream
count() - Method in interface com.aol.simple.react.stream.traits.FutureStream
 

D

debounce(long, TimeUnit) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Can be used to debounce (accept a single data point from a unit of time) data.
debounce(long, TimeUnit) - Method in interface com.aol.simple.react.stream.traits.FutureStream
Can be used to debounce (accept a single data point from a unit of time) data.
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.
defaultValue - Static variable in class com.aol.simple.react.stream.lazy.ParallelReductionConfig
 
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.EagerFutureStream
 
distinct() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
DoNothingMonitor - Class in com.aol.simple.react.capacity.monitor
Use this class to switch off capacity monitoring
DoNothingMonitor() - Constructor for class com.aol.simple.react.capacity.monitor.DoNothingMonitor
 
doOnEach(Function<U, U>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Can only be used on Eager Streams 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
Can only be used on Eager Streams Applies a function to this phase independent on the main flow.
doOnEachSync(Function<U, U>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
drainToOrBlock() - Method in class com.aol.simple.react.async.Queue.QueueReader
 
duplicate() - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Duplicate a Stream into two equivalent LazyFutureStreams, Streams are duplicated as results of Futures are populated
duplicate() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Duplicate a Streams into two equivalent Streams.
duplicateFutures() - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Duplicate a Stream into two equivalent LazyFutureStreams, underlying Stream of Futures is duplicated
duplicateFutures() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Duplicate a Stream into two equivalent LazyFutureStreams LazyFutureStream.of(1, 2, 3).duplicate() results in tuple((1,2,3),(1,2,3)) Care should be taken not to use this method with infinite streams!
duplicateFuturesSeq() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Duplicate a Stream into two equivalent Sequences LazyFutureStream.of(1, 2, 3).duplicate() results in tuple((1,2,3),(1,2,3)) Care should be taken not to use this method with infinite streams!

E

EagerFutureStream<U> - Interface in com.aol.simple.react.stream.traits
Static Factory methods for Simple React Flows
EagerFutureStreamComprehender - Class in com.aol.simple.react.monad
Cyclops Monad Comprehender for EagerFutureStreams
EagerFutureStreamComprehender() - Constructor for class com.aol.simple.react.monad.EagerFutureStreamComprehender
 
EagerFutureStreamImpl<U> - Class in com.aol.simple.react.stream.eager
 
EagerFutureStreamImpl(EagerReact, Stream<CompletableFuture<U>>) - Constructor for class com.aol.simple.react.stream.eager.EagerFutureStreamImpl
Construct a SimpleReact stage - this acts as a fluent SimpleReact builder
EagerFutureStreamImpl(EagerReact, Stream<CompletableFuture<U>>, List<CompletableFuture>) - Constructor for class com.aol.simple.react.stream.eager.EagerFutureStreamImpl
 
EagerReact - Class in com.aol.simple.react.stream.eager
Builder class for EagerFutureStreams react methods - submit Suppliers to task executor of methods - build Streams directly from data
EagerReact(Executor, RetryExecutor, Boolean) - Constructor for class com.aol.simple.react.stream.eager.EagerReact
 
EagerReact() - Constructor for class com.aol.simple.react.stream.eager.EagerReact
Construct a EagerReact builder using standard thread pool.
EagerReact(Executor) - Constructor for class com.aol.simple.react.stream.eager.EagerReact
Construct a EagerReact builder with provided Executor
eagerReact - Static variable in class com.aol.simple.react.threads.ParallelElasticPools
 
eagerReact - Static variable in class com.aol.simple.react.threads.SequentialElasticPools
 
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.
empty() - Method in class com.aol.simple.react.monad.EagerFutureStreamComprehender
 
empty() - Method in class com.aol.simple.react.monad.LazyFutureStreamComprehender
 
empty() - Method in class com.aol.simple.react.monad.SimpleReactStreamComprehender
 
empty() - Static method in class com.aol.simple.react.stream.traits.Continuation
 
empty() - Static method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
empty() - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
empty() - Static method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
EmptyCollector<T> - Class in com.aol.simple.react.collectors.lazy
A collector that periodically joins active completablefutures but does not store the results
EmptyCollector() - Constructor for class com.aol.simple.react.collectors.lazy.EmptyCollector
 
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
 
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
 
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

filter(EagerFutureStream, Predicate) - Method in class com.aol.simple.react.monad.EagerFutureStreamComprehender
 
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.EagerFutureStream
 
filter(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
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.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.SimpleReactStream
Synchronous filtering operation Removes elements that do not match the supplied predicate from the dataflow
findAny() - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
findFirst() - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
findFirst() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Returns an Optional describing the first element of this stream, or an empty Optional if the stream is empty.
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(EagerFutureStream<U>...) - Static method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Return first Stream out of provided Streams that starts emitted results
firstOf(FutureStream<U>...) - Static method in interface com.aol.simple.react.stream.traits.FutureStream
Return first Stream out of provided Streams that starts emitted results
firstOf(LazyFutureStream<U>...) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Return first Stream out of provided Streams that starts emitted results
fixedDelay(long, TimeUnit) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Apply a fixed delay before emitting elements to the next phase of the Stream.
fixedDelay(long, TimeUnit) - Method in interface com.aol.simple.react.stream.traits.FutureStream
Apply a fixed delay before emitting elements to the next phase of the Stream.
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(EagerFutureStream, Function) - Method in class com.aol.simple.react.monad.EagerFutureStreamComprehender
 
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.EagerFutureStream
 
flatMap(Function<? super U, ? extends Stream<? extends R>>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
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.SimpleReactStream
Allows aggregate values in a Stream to be flatten into a single Stream.
flatMapToDouble(Function<? super U, ? extends DoubleStream>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
flatMapToInt(Function<? super U, ? extends IntStream>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
flatMapToLong(Function<? super U, ? extends LongStream>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
forEach(Consumer<? super T>, Function<CompletableFuture, T>) - Method in class com.aol.simple.react.collectors.lazy.IncrementalReducer
 
forEach(Consumer<? super U>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
Stream supporting methods
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.FutureStream
 
forEachResults(Collection<CompletableFuture<T>>, Consumer<? super T>, Function<CompletableFuture, T>) - Method in class com.aol.simple.react.collectors.lazy.IncrementalReducer
 
fromListCompletableFuture(List<CompletableFuture<R>>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
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.eager.EagerReact
 
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.EagerFutureStream
 
fromStream(Stream<R>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
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<CompletableFuture<R>>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
fromStreamOfFutures(Stream<CompletableFuture<R>>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
fromStreamOfFutures(Stream<CompletableFuture<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
FutureStream<U> - Interface in com.aol.simple.react.stream.traits
 
FutureStream.Val<T> - Class in com.aol.simple.react.stream.traits
 

G

generate() - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
generate(T) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
generate(Supplier<T>) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
get() - Method in class com.aol.simple.react.async.Queue
 
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
 
getBlocking() - Method in class com.aol.simple.react.collectors.lazy.EmptyCollector
 
getBlocking() - Method in interface com.aol.simple.react.collectors.lazy.LazyResultConsumer
 
getBlocking() - 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.ConfigurableStream
 
getErrorHandler() - Method in interface com.aol.simple.react.stream.traits.LazyStream
 
getErrors() - Method in class com.aol.simple.react.stream.Status
 
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.stream.traits.ConfigurableStream
 
getLastActive() - Method in interface com.aol.simple.react.stream.traits.LazyStream
 
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.collectors.lazy.LazyResultConsumer
 
getMaxActive() - Method in class com.aol.simple.react.collectors.lazy.SamplingCollector
 
getOriginalFutures() - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
getParallelReduction() - Method in interface com.aol.simple.react.stream.traits.LazyStream
 
getPopulator() - Method in class com.aol.simple.react.stream.eager.EagerFutureStreamImpl
 
getPopulator() - Method in class com.aol.simple.react.stream.lazy.LazyFutureStreamImpl
 
getPopulator() - Method in class com.aol.simple.react.stream.simple.SimpleReactStreamImpl
 
getPopulator() - Method in interface com.aol.simple.react.stream.traits.LazyToQueue
 
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.eager.EagerFutureStreamImpl
 
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
 
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.ConfigurableStream
 
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
 
getSubscription() - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
getTargetClass() - Method in class com.aol.simple.react.monad.EagerFutureStreamComprehender
 
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.eager.EagerFutureStreamImpl
 
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.ConfigurableStream
 
getTotal() - Method in class com.aol.simple.react.stream.Status
 
getValue() - Method in exception com.aol.simple.react.exceptions.SimpleReactFailedStageException
 
getWaitStrategy() - Method in interface com.aol.simple.react.stream.traits.LazyStream
 

H

handleExceptions(Function<U, R>) - Static method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
hasNext() - Method in class com.aol.simple.react.stream.CloseableIterator
 

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
 
intersperse(U) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
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.FutureStream
Returns a stream with a given value interspersed between any two values of this stream.
intersperse(FutureStream<T>, T) - Static method in interface com.aol.simple.react.stream.traits.FutureStream
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.
isAsync() - Method in class com.aol.simple.react.stream.BaseSimpleReact
 
isAsync() - Method in class com.aol.simple.react.stream.eager.EagerFutureStreamImpl
 
isAsync() - Method in class com.aol.simple.react.stream.eager.EagerReact
 
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.ConfigurableStream
 
isDataPresent() - Method in exception com.aol.simple.react.async.Queue.ClosedQueueException
 
isEager() - Method in interface com.aol.simple.react.stream.traits.ConfigurableStream
 
isOpen() - Method in class com.aol.simple.react.async.Queue.QueueReader
 
isParallel() - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
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.BaseLazySimpleReact
Iterate infinitely using the supplied seed and function
iterateInfinitely(U, UnaryOperator<U>) - Method in class com.aol.simple.react.stream.lazy.LazyReact
 
iterator() - Method in interface com.aol.simple.react.stream.traits.FutureStream
 

J

jitter(long) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Introduce a random delay between events in a stream Can be used to prevent behaviour synchronizing within a system
jitter(long) - Method in interface com.aol.simple.react.stream.traits.FutureStream
Introduce a random delay between events in a stream Can be used to prevent behaviour synchronizing within a system
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(SimpleReactStream<SimpleReactStream<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(StreamWrapper) - 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
LazyFutureStreamComprehender - Class in com.aol.simple.react.monad
Cyclops Monad Comprehender for LazyFutureStreams
LazyFutureStreamComprehender() - Constructor for class com.aol.simple.react.monad.LazyFutureStreamComprehender
 
LazyFutureStreamImpl<U> - Class in com.aol.simple.react.stream.lazy
 
LazyFutureStreamImpl(LazyReact, Stream<CompletableFuture<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) - 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
 
LazyResultConsumer<T> - Interface in com.aol.simple.react.collectors.lazy
Interface that defines the rules for Collecting results from Infinite SimpleReact Streams
LazyStream<U> - Interface in com.aol.simple.react.stream.traits
 
LazyToQueue<U> - Interface in com.aol.simple.react.stream.traits
 
lift(Function<T, R>) - Static method in interface com.aol.simple.react.stream.traits.FutureStream
 
lift2(BiFunction<T1, T2, R>) - Static method in interface com.aol.simple.react.stream.traits.FutureStream
 
limit(long) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
limit(long) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
limitFutures(long) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Perform a limit operation on the underlying Stream of Futures In contrast to EagerFutureStream#limit this removes entries basaed on their start position
LimitingMonitor - Class in com.aol.simple.react.capacity.monitor
Class to be used to limit the number of active CompletableFuture Streams, in an infinite SimpleReact stream.
LimitingMonitor() - Constructor for class com.aol.simple.react.capacity.monitor.LimitingMonitor
Limiting Monitor with default capacity settings
limitUntil(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Returns a stream limited to all elements for which a predicate evaluates to false.
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.
limitUntil(Stream<T>, Predicate<? super T>) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Returns a stream ed to all elements for which a predicate evaluates to true.
limitWhile(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Returns a stream limited to all elements for which a predicate evaluates to true.
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.
limitWhile(Stream<T>, Predicate<? super T>) - Static 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.StreamWrapper
 

M

map(EagerFutureStream, Function) - Method in class com.aol.simple.react.monad.EagerFutureStreamComprehender
 
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.EagerFutureStream
 
map(Function<? super U, ? extends R>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
map(Function<? super U, ? extends R>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
mapToDouble(ToDoubleFunction<? super U>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
mapToInt(ToIntFunction<? super U>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
mapToLong(ToLongFunction<? super U>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
max(Comparator<? super U>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
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.
MaxActive.defaultValue - Enum in com.aol.simple.react.config
 
merge(SimpleReactStream<U>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
merge(SimpleReactStream<U>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
merge(FutureStream, FutureStream) - Static method in interface com.aol.simple.react.stream.traits.FutureStream
Merge this reactive dataflow with another - recommended for merging different types.
merge(SimpleReactStream<U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
merge(SimpleReactStream<U>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Merge this reactive dataflow with another of the same type.
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.
min(Comparator<? super U>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
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() - 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.FutureStream
 
notEmpty() - Method in class com.aol.simple.react.async.Queue.QueueReader
 
NULL - Static variable in interface com.aol.simple.react.stream.traits.LazyFutureStream
 

O

of(Object) - Method in class com.aol.simple.react.monad.EagerFutureStreamComprehender
 
of(Object) - Method in class com.aol.simple.react.monad.LazyFutureStreamComprehender
 
of(Object) - Method in class com.aol.simple.react.monad.SimpleReactStreamComprehender
 
of(Iterator<U>) - Method in class com.aol.simple.react.stream.BaseSimpleReact
Start a reactive flow from a JDK Iterator
of(Collection<R>) - Method in class com.aol.simple.react.stream.BaseSimpleReact
Start a reactive flow from a Collection using an Iterator
of(Stream<U>) - Method in class com.aol.simple.react.stream.BaseSimpleReact
Start a reactive dataflow from a stream.
of(IntStream) - Method in class com.aol.simple.react.stream.BaseSimpleReact
Start a reactive dataflow from a stream.
of(DoubleStream) - Method in class com.aol.simple.react.stream.BaseSimpleReact
Start a reactive dataflow from a stream.
of(LongStream) - Method in class com.aol.simple.react.stream.BaseSimpleReact
Start a reactive dataflow from a stream.
of(U...) - Method in class com.aol.simple.react.stream.BaseSimpleReact
 
of(Stream<U>) - Method in class com.aol.simple.react.stream.eager.EagerReact
 
of(IntStream) - Method in class com.aol.simple.react.stream.eager.EagerReact
 
of(DoubleStream) - Method in class com.aol.simple.react.stream.eager.EagerReact
 
of(LongStream) - Method in class com.aol.simple.react.stream.eager.EagerReact
 
of(U...) - Method in class com.aol.simple.react.stream.eager.EagerReact
 
of(Iterator<U>) - Method in class com.aol.simple.react.stream.eager.EagerReact
Start a LazyFutureStream from a JDK Iterator
of(Collection<R>) - Method in class com.aol.simple.react.stream.eager.EagerReact
Start a EagerFutureStream from a Collection
of(Stream<U>) - Method in class com.aol.simple.react.stream.lazy.LazyReact
 
of(IntStream) - Method in class com.aol.simple.react.stream.lazy.LazyReact
 
of(DoubleStream) - Method in class com.aol.simple.react.stream.lazy.LazyReact
 
of(LongStream) - Method in class com.aol.simple.react.stream.lazy.LazyReact
 
of(U...) - Method in class com.aol.simple.react.stream.lazy.LazyReact
 
of(Iterator<U>) - Method in class com.aol.simple.react.stream.lazy.LazyReact
Start a LazyFutureStream from a JDK Iterator
of(Collection<R>) - Method in class com.aol.simple.react.stream.lazy.LazyReact
Start a LazyFutureStream from a Collection
of(T) - Static method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Create a sequential synchronous stream
of(T...) - Static method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Create a sequential synchronous stream
of(Stream<T>) - Static method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Wrap a Stream into a Sequential synchronous FutureStream.
of(Iterator<T>) - Static method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Wrap an Iterator into a FutureStream.
of(T) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
of(T...) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
of(Stream<T>) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Wrap a Stream into a FutureStream.
of(Iterator<T>) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Wrap an Iterator into a FutureStream.
of(T) - Static method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
of(T...) - Static method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
of(Stream<T>) - Static method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Wrap a Stream into a SimpleReactStream.
of(Iterator<T>) - Static method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Wrap an Iterator into a FutureStream.
offer(T) - Method in interface com.aol.simple.react.async.Adapter
Offer a single datapoint to this adapter
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
ofIterable(Iterable<U>) - Method in class com.aol.simple.react.stream.BaseSimpleReact
Start a reactive flow from a JDK Iterator
ofIterable(Iterable<U>) - Method in class com.aol.simple.react.stream.eager.EagerReact
 
ofIterable(Iterable<U>) - Method in class com.aol.simple.react.stream.lazy.LazyReact
 
ofIterable(Iterable<T>) - Static method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Wrap an Iterable into a FutureStream.
ofIterable(Iterable<T>) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Wrap an Iterable into a FutureStream.
ofIterable(Iterable<T>) - Static method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Wrap an Iterable into a FutureStream.
ofType(Class<U>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
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.FutureStream
 
ofType(FutureStream<T>, Class<U>) - Static method in interface com.aol.simple.react.stream.traits.FutureStream
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.EagerFutureStream
 
onClose(Runnable) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
onClose(Runnable) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
onePer(long, TimeUnit) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Slow emissions down, emiting one element per specified time period
onePer(long, TimeUnit) - Method in interface com.aol.simple.react.stream.traits.FutureStream
Slow emissions down, emiting one element per specified time period
onePer(long, TimeUnit) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Slow emissions down, emiting one element per specified time period
onFail(Function<? extends SimpleReactFailedStageException, U>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
onFail(Class<? extends Throwable>, Function<? extends SimpleReactFailedStageException, U>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
onFail(Function<? extends SimpleReactFailedStageException, U>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
onFail(Class<? extends Throwable>, Function<? extends SimpleReactFailedStageException, U>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
onFail(Function<? extends SimpleReactFailedStageException, U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
onFail(Class<? extends Throwable>, Function<? extends SimpleReactFailedStageException, U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
onFail(Function<? extends 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<? extends SimpleReactFailedStageException, U>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Recover for a particular class of exceptions only.

P

parallel(U...) - Static method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Construct an Eager SimpleReact Stream from specified array
parallel() - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
parallel(U...) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Construct an Lazy SimpleReact Stream from specified array
parallel() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
parallelBuilder() - Static method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
parallelBuilder(int) - Static method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Construct a new EagerReact builder, with a new task executor and retry executor with configured number of threads
parallelBuilder() - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
parallelBuilder(int) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Construct a new LazyReact builder, with a new task executor and retry executor with configured number of threads
parallelBuilder() - Static method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
parallelBuilder(int) - Static method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Construct a new SimpleReact builder, with a new task executor and retry executor with configured number of threads
parallelCommonBuilder() - Static method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
parallelCommonBuilder() - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
parallelCommonBuilder() - Static method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
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
 
parallelOf(U...) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Construct a SimpleReact Stage from a supplied array
parallelOf(U...) - Static method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Construct a SimpleReact Stage from a supplied array
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
 
partition(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Partition a stream into two given a predicate.
partition(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Partition a stream into two given a predicate.
partitionFutureStream(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Partition an EagerFutureStream into two EagerFutureStreams given a predicate.
peek(Consumer<? super U>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
peek(Consumer<? super U>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
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.SimpleReactStream
Peek asynchronously at the results in the current stage.
peekSync(Consumer<? super U>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Synchronous peek operator
populate(REACTOR) - Method in class com.aol.simple.react.threads.ReactPool
 
priority - Static variable in class com.aol.simple.react.monad.EagerFutureStreamComprehender
 
priority() - Method in class com.aol.simple.react.monad.EagerFutureStreamComprehender
 
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
 
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
 

Q

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.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
 
QueueFactories() - Constructor for class com.aol.simple.react.async.QueueFactories
 
QueueFactory<T> - Interface in com.aol.simple.react.async
 
QueueReader() - Constructor for class com.aol.simple.react.async.Queue.QueueReader
 
QueueTimeoutException() - Constructor for exception com.aol.simple.react.async.Queue.QueueTimeoutException
 

R

range(int, int) - Method in class com.aol.simple.react.stream.BaseSimpleReact
 
range(int, int) - Method in class com.aol.simple.react.stream.eager.EagerReact
 
range(int, int) - Method in class com.aol.simple.react.stream.lazy.LazyReact
 
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.eager.EagerReact
 
react(Collection<Supplier<U>>) - Method in class com.aol.simple.react.stream.eager.EagerReact
 
react(Stream<Supplier<U>>) - Method in class com.aol.simple.react.stream.eager.EagerReact
 
react(Iterator<Supplier<U>>) - Method in class com.aol.simple.react.stream.eager.EagerReact
 
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(Collection<Supplier<U>>) - Method in class com.aol.simple.react.stream.simple.SimpleReact
Start a reactive dataflow with a list of one-off-suppliers
react(Stream<Supplier<U>>) - Method in class com.aol.simple.react.stream.simple.SimpleReact
Start a reactive dataflow with a list of one-off-suppliers
react(Iterator<Supplier<U>>) - Method in class com.aol.simple.react.stream.simple.SimpleReact
Start a reactive dataflow with a list of one-off-suppliers
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.EagerFutureStream
Create a parallel asynchronous stream
react(Supplier<T>...) - Static method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Create a parallel asynchronous stream
react(Supplier<T>) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Create a parallel asynchronous stream
react(Supplier<T>...) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Create a parallel asynchronous stream
react(Supplier<T>) - Static method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Create a parallel asynchronous stream
react(Supplier<T>...) - Static method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Create a parallel asynchronous stream
react(Function<REACTOR, T>) - Method in class com.aol.simple.react.threads.ReactPool
 
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.BaseLazySimpleReact
Generate an infinite reactive flow.
reactInfinitely(Supplier<U>) - Method in class com.aol.simple.react.stream.lazy.LazyReact
Generate an infinite LazyFutureStream The flow will run indefinitely unless / until the provided Supplier throws an Exception
reactInfinitelyAsync(Supplier<U>) - Method in class com.aol.simple.react.stream.BaseLazySimpleReact
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<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.eager.EagerReact
 
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
ReactPool<REACTOR extends BaseSimpleReact> - 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
reduce(Function<CompletableFuture, T>, T, BinaryOperator<T>) - Method in class com.aol.simple.react.collectors.lazy.IncrementalReducer
 
reduce(Function<CompletableFuture, T>, BinaryOperator<T>) - Method in class com.aol.simple.react.collectors.lazy.IncrementalReducer
 
reduce(Function<CompletableFuture, T>, U, BiFunction<U, ? super T, U>, BinaryOperator<U>) - Method in class com.aol.simple.react.collectors.lazy.IncrementalReducer
 
reduce(U, BinaryOperator<U>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
reduce(BinaryOperator<U>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
reduce(R, BiFunction<R, ? super U, R>, BinaryOperator<R>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
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(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<CompletableFuture<T>>, Function<CompletableFuture, T>, T, BinaryOperator<T>) - Method in class com.aol.simple.react.collectors.lazy.IncrementalReducer
 
reduceResults(Collection<CompletableFuture<T>>, Function<CompletableFuture, T>, BinaryOperator<T>) - Method in class com.aol.simple.react.collectors.lazy.IncrementalReducer
 
reduceResults(Collection<CompletableFuture<T>>, Function<CompletableFuture, T>, U, BiFunction<U, ? super T, U>, BinaryOperator<U>) - Method in class com.aol.simple.react.collectors.lazy.IncrementalReducer
 
registerLimit(long) - Method in class com.aol.simple.react.async.AlwaysContinue
 
registerLimit(long) - Method in interface com.aol.simple.react.async.Continueable
 
registerLimit(long) - Method in class com.aol.simple.react.async.Subscription
 
registerSkip(long) - Method in class com.aol.simple.react.async.AlwaysContinue
 
registerSkip(long) - Method in interface com.aol.simple.react.async.Continueable
 
registerSkip(long) - Method in class com.aol.simple.react.async.Subscription
 
resolveForCrossTypeFlatMap(Comprehender, SimpleReactStream) - Method in class com.aol.simple.react.monad.SimpleReactStreamComprehender
 
retry(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
retry(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
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.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(BaseSimpleReact) - Method in class com.aol.simple.react.stream.eager.EagerFutureStreamImpl
 
returnPopulator(BaseSimpleReact) - Method in class com.aol.simple.react.stream.lazy.LazyFutureStreamImpl
 
returnPopulator(BaseSimpleReact) - Method in class com.aol.simple.react.stream.simple.SimpleReactStreamImpl
 
returnPopulator(T) - Method in interface com.aol.simple.react.stream.traits.LazyToQueue
 
reverse() - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Reverse a stream.
reverse() - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
reverse() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Reverse a stream.
reversedIterator() - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
run(StreamWrapper, EmptyCollector) - Method in class com.aol.simple.react.stream.Runner
 
run(Executor) - Method in interface com.aol.simple.react.stream.traits.LazyStream
Trigger a lazy stream as a task on the provided Executor
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(StreamWrapper, EmptyCollector) - Method in class com.aol.simple.react.stream.Runner
 
Runner - Class in com.aol.simple.react.stream
 
Runner() - Constructor for class com.aol.simple.react.stream.Runner
 
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

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
 
SamplingMonitor - Class in com.aol.simple.react.capacity.monitor
Use this class to sample the CompletableFuture chains in an infinite flow as they are created Can be used to with a LimitingMonitor to reduce touch points
SamplingMonitor(Consumer<CompletableFuture>) - Constructor for class com.aol.simple.react.capacity.monitor.SamplingMonitor
Sampling monitor that will pass control to supplied monitor when sampling triggered.
scanLeft(T, BiFunction<T, ? super U, T>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Scan a stream to the left.
scanLeft(T, BiFunction<T, ? super U, T>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Scan a stream to the left.
scanRight(R, BiFunction<? super U, R, R>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Scan a stream to the right.
scanRight(R, BiFunction<? super U, R, R>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Scan a stream to the right.
self(Consumer<FutureStream<U>>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Give a function access to the current stage of a SimpleReact Stream
self(Consumer<FutureStream<U>>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
Give a function access to the current stage of a SimpleReact Stream
self(Consumer<FutureStream<U>>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Give a function access to the current stage of a SimpleReact Stream
sequential() - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
sequential() - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
sequential() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
sequentialBuilder() - Static method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
sequentialBuilder() - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
sequentialBuilder() - Static method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
sequentialCommonBuilder() - Static method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
sequentialCommonBuilder() - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
sequentialCommonBuilder() - Static method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
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.Signal
Set the current value of this signal
shard(Map<K, Queue<U>>, Function<U, K>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Break a stream into multiple Streams based of some characteristic of the elements of the Stream e.g.
shard(Map<K, Queue<U>>, Function<U, K>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
Break a stream into multiple Streams based of some characteristic of the elements of the Stream e.g.
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.EagerFutureStream
Shuffle a stream
shuffle(Random) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Shuffle a stream using specified source of randomness
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) - 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, 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
 
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<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
 
SimpleReactStreamImpl<U> - Class in com.aol.simple.react.stream.simple
 
SimpleReactStreamImpl(SimpleReact, Stream<CompletableFuture<U>>, List<CompletableFuture>) - 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
 
skip(long) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
skip(long) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
skipFutures(long) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
In contast to EagerFutureStream#skip skipFutures will skip the first n entries of the underlying Stream of Futures.
skipUntil(FutureStream<T>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Return a Stream with the same values as this Stream, but with all values omitted until the provided stream starts emitting values.
skipUntil(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Returns a stream with all elements skipped for which a predicate evaluates to false.
skipUntil(FutureStream<T>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
Return a Stream with the same values as this Stream, but with all values omitted until the provided stream starts emitting values.
skipUntil(FutureStream<T1>, FutureStream<T2>) - Static method in interface com.aol.simple.react.stream.traits.FutureStream
 
skipUntil(FutureStream<T>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Return a Stream with the same values as this Stream, but with all values omitted until the provided stream starts emitting values.
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.
skipWhile(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Returns a stream with all elements skipped for which a predicate evaluates to true.
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.EagerFutureStream
Returns a limited interval from a given Stream.
slice(long, long) - Method in interface com.aol.simple.react.stream.traits.FutureStream
Returns a limited interval from a given Stream.
slice(FutureStream<T>, long, long) - Static method in interface com.aol.simple.react.stream.traits.FutureStream
Returns a limited interval from a given Stream.
slice(long, long) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
sliceFutures(long, long) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Returns a limited interval from a given Stream.
softener - Static variable in interface com.aol.simple.react.stream.traits.FutureStream
 
sorted() - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
sorted(Comparator<? super U>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
sorted() - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
sorted(Comparator<? super U>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
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
 
splitAt(long) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Split a EagerFutureStream at a given position.
splitAtFutures(long) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Split a stream at a given position.
splitAtFutureStream(long) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Split a EagerFutureStream at a given position.
splitAtHead() - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Split a stream at the head.
splitAtHeadFutureStream() - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
SplitAtHead but return type is EagerFutureStream
spliterator() - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
StageWithResults<RS,U> - Class in com.aol.simple.react.stream
 
StageWithResults(ConfigurableStream<U>, RS) - Constructor for class com.aol.simple.react.stream.StageWithResults
 
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() - 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(Function<Stream<CompletableFuture>, Stream<CompletableFuture>>) - Method in class com.aol.simple.react.stream.StreamWrapper
 
stream() - Method in class com.aol.simple.react.stream.StreamWrapper
 
stream() - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
stream() - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
stream() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
streamBatch(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.SimpleReactStream
 
streamControl(Continueable, Function<Supplier<T>, Supplier<T>>) - Method in class com.aol.simple.react.async.Queue
 
StreamWrapper - Class in com.aol.simple.react.stream
 
StreamWrapper(List<CompletableFuture>) - Constructor for class com.aol.simple.react.stream.StreamWrapper
 
StreamWrapper(StreamWrapper.AsyncList) - Constructor for class com.aol.simple.react.stream.StreamWrapper
 
StreamWrapper(Stream<CompletableFuture>, boolean) - Constructor for class com.aol.simple.react.stream.StreamWrapper
 
StreamWrapper(Stream<CompletableFuture>, Collector, boolean) - Constructor for class com.aol.simple.react.stream.StreamWrapper
 
StreamWrapper(CompletableFuture, boolean) - Constructor for class com.aol.simple.react.stream.StreamWrapper
 
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
Subscription - Class in com.aol.simple.react.async
 
Subscription() - Constructor for class com.aol.simple.react.async.Subscription
 
sync() - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
sync() - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
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.QueueFactories
 
syncrhonousPool() - Static method in class com.aol.simple.react.threads.ReactPool
 

T

takeUntil(FutureStream<T>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Return a Stream with the same values, but will stop emitting values once the provided Stream starts to emit values.
takeUntil(FutureStream<T>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
Return a Stream with the same values, but will stop emitting values once the provided Stream starts to emit values.
takeUntil(FutureStream<T1>, FutureStream<T2>) - Static method in interface com.aol.simple.react.stream.traits.FutureStream
 
takeUntil(FutureStream<T>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
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.EagerFutureStream
 
then(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
then(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
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
Override return type on SimpleReactStream
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.
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.EagerFutureStream
 
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.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
 
throwSoftenedException(Throwable) - Method in class com.aol.simple.react.exceptions.ExceptionSoftener
 
ThrowsSoftened - Annotation Type in com.aol.simple.react.exceptions
 
toArray() - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
toArray(IntFunction<A[]>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
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.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.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
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.QueueFactories
 
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.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.EagerFutureStream
 
unordered() - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
unordered() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 

V

Val() - Constructor for class com.aol.simple.react.stream.traits.FutureStream.Val
 
valueOf(String) - Static method in enum com.aol.simple.react.config.MaxActive.defaultValue
Returns the enum constant of this type with the specified name.
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.
values() - Static method in enum com.aol.simple.react.config.MaxActive.defaultValue
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.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.

W

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.eager.EagerFutureStreamImpl
 
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.SimpleReactConfigurableStream
 
withAsync(boolean) - Method in interface com.aol.simple.react.stream.traits.ConfigurableStream
 
withAsync(boolean) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
withAsync(boolean) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
withErrorHandler(Optional<Consumer<Throwable>>) - Method in interface com.aol.simple.react.stream.traits.ConfigurableStream.SimpleReactConfigurableStream
 
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.EagerFutureStream
 
withErrorHandler(Optional<Consumer<Throwable>>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
withLastActive(StreamWrapper) - Method in interface com.aol.simple.react.stream.traits.ConfigurableStream.SimpleReactConfigurableStream
 
withLastActive(StreamWrapper) - Method in interface com.aol.simple.react.stream.traits.ConfigurableStream
 
withLastActive(StreamWrapper) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
withLastActive(StreamWrapper) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
withLatest(FutureStream<T>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Similar to zip and combineLatest, except will always take the latest from this Stream while taking the last available value from the provided stream.
withLatest(FutureStream<T>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
Similar to zip and combineLatest, except will always take the latest from this Stream while taking the last available value from the provided stream.
withLatest(FutureStream<T1>, FutureStream<T2>) - Static method in interface com.aol.simple.react.stream.traits.FutureStream
Zip two streams into one.
withLatest(FutureStream<T1>, FutureStream<T2>, BiFunction<T1, T2, R>) - Static method in interface com.aol.simple.react.stream.traits.FutureStream
Zip two streams into one using a BiFunction to produce resulting.
withLatest(FutureStream<T>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Similar to zip and combineLatest, except will always take the latest from this Stream while taking the last available value from the provided stream.
withLazyCollector(LazyResultConsumer<U>) - Method in interface com.aol.simple.react.stream.traits.ConfigurableStream.SimpleReactConfigurableStream
 
withLazyCollector(LazyResultConsumer<T>) - Method in interface com.aol.simple.react.stream.traits.ConfigurableStream
 
withLazyCollector(LazyResultConsumer<U>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
withLazyCollector(LazyResultConsumer<U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
withNewStream(Stream<CompletableFuture>) - Method in class com.aol.simple.react.stream.StreamWrapper
 
withParallelReduction(ParallelReductionConfig) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
withQueueFactory(QueueFactory<U>) - Method in interface com.aol.simple.react.stream.traits.ConfigurableStream.SimpleReactConfigurableStream
 
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.EagerFutureStream
 
withQueueFactory(QueueFactory<U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
withResults(Collection<CompletableFuture<T>>) - Method in class com.aol.simple.react.collectors.lazy.EmptyCollector
 
withResults(Collection<CompletableFuture<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<CompletableFuture<T>>) - Method in class com.aol.simple.react.collectors.lazy.SamplingCollector
 
withRetrier(RetryExecutor) - Method in class com.aol.simple.react.stream.eager.EagerFutureStreamImpl
 
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.ConfigurableStream.SimpleReactConfigurableStream
 
withRetrier(RetryExecutor) - Method in interface com.aol.simple.react.stream.traits.ConfigurableStream
 
withRetrier(RetryExecutor) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
withRetrier(RetryExecutor) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
withSubscription(Continueable) - Method in interface com.aol.simple.react.stream.traits.ConfigurableStream.SimpleReactConfigurableStream
 
withSubscription(Continueable) - Method in interface com.aol.simple.react.stream.traits.ConfigurableStream
 
withSubscription(Continueable) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
withSubscription(Continueable) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
withTaskExecutor(Executor) - Method in class com.aol.simple.react.stream.eager.EagerFutureStreamImpl
 
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.SimpleReactConfigurableStream
 
withTaskExecutor(Executor) - Method in interface com.aol.simple.react.stream.traits.ConfigurableStream
 
withTaskExecutor(Executor) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
withTaskExecutor(Executor) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
withWaitStrategy(Consumer<CompletableFuture>) - Method in interface com.aol.simple.react.stream.traits.ConfigurableStream.SimpleReactConfigurableStream
 
withWaitStrategy(Consumer<CompletableFuture>) - Method in interface com.aol.simple.react.stream.traits.ConfigurableStream
 
withWaitStrategy(Consumer<CompletableFuture>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
withWaitStrategy(Consumer<CompletableFuture>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 

X

xPer(int, long, TimeUnit) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Allows x (specified number of) emissions with a time period before stopping emmissions until specified time has elapsed since last emission
xPer(int, long, TimeUnit) - Method in interface com.aol.simple.react.stream.traits.FutureStream
Allows x (specified number of) emissions with a time period before stopping emmissions until specified time has elapsed since last emission
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

Z

zip(Seq<R>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Zip two streams into one.
zip(Seq<T>, BiFunction<U, T, R>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Zip two streams into one using a BiFunction to produce resulting values.
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<T1>, Stream<T2>) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Zip two streams into one.
zip(Stream<T1>, Stream<T2>, BiFunction<T1, T2, R>) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Zip two streams into one using a BiFunction to produce resulting values.
zipFutures(Stream<R>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Zip two Streams, zipping against the underlying futures of this stream
zipFutures(FutureStream<R>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
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
zipFutures(Stream<R>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
Zip two Streams, zipping against the underlying futures of this stream
zipFutures(FutureStream<R>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
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
zipFutures(Stream<R>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Zip two Streams, zipping against the underlying futures of this stream
zipFutures(FutureStream<R>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
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
zipFuturesWithIndex() - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Zip this Stream with an index, but Zip based on the underlying tasks, not completed results.
zipFuturesWithIndex() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Zip this Stream with an index, but Zip based on the underlying tasks, not completed results.
zipWithIndex() - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Zip a Stream with a corresponding Stream of indexes.
zipWithIndex() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Zip a Stream with a corresponding Stream of indexes.
A B C D E F G H I J L M N O P Q R S T U V W X Z 
Skip navigation links