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

A

AbstractPushableStream<T,X extends Adapter<T>,R extends java.util.stream.Stream<T>> - Class in com.aol.simple.react.stream.pushable
 
AbstractPushableStream(X, R) - Constructor for class com.aol.simple.react.stream.pushable.AbstractPushableStream
 
accept(FastFuture<T>) - Method in class com.aol.simple.react.collectors.lazy.BatchingCollector
 
accept(FastFuture<T>) - Method in class com.aol.simple.react.collectors.lazy.EmptyCollector
 
accept(FastFuture<T>) - Method in class com.aol.simple.react.collectors.lazy.SamplingCollector
 
Adapter<T> - Interface in com.aol.simple.react.async
Interface for an Adapter that inputs data from 1 or more input Streams and sends it to 1 or more output Streams
add(Object) - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
add(T) - Method in class com.aol.simple.react.async.Queue
Add a single data point to the queue If the queue is a bounded queue and is full, will return false
add(FastFuture<T>) - Method in class com.aol.simple.react.collectors.lazy.EmptyCollector
 
add(U, Queue<U>) - Method in interface com.aol.simple.react.stream.traits.LazyToQueue
 
addAll(Collection) - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
addContinuation(Continuation) - Method in interface com.aol.simple.react.async.ContinuationStrategy
 
addContinuation(Continuation) - Method in class com.aol.simple.react.async.Queue
 
addContinuation(Continuation) - Method in class com.aol.simple.react.async.SingleContinuation
 
addContinuation(Continuation) - Method in class com.aol.simple.react.async.StreamOfContinuations
 
addQueue(Queue) - Method in class com.aol.simple.react.async.subscription.AlwaysContinue
 
addQueue(Queue) - Method in interface com.aol.simple.react.async.subscription.Continueable
 
addQueue(Queue) - Method in class com.aol.simple.react.async.subscription.Subscription
 
addToQueue(Queue) - Method in interface com.aol.simple.react.stream.traits.EagerToQueue
 
addToQueue(Queue) - Method in interface com.aol.simple.react.stream.traits.LazyToQueue
 
addToQueue(Queue) - Method in interface com.aol.simple.react.stream.traits.ToQueue
 
allMatch(Predicate<? super T>) - Method in class com.aol.simple.react.stream.traits.FutureOps
Perform an asynchronous All Match operation
allMatch(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
allOf(Runnable, FastFuture...) - Static method in class com.aol.simple.react.async.future.FastFuture
 
allOf(Collector, Function<T, R>) - Method in class com.aol.simple.react.stream.simple.SimpleReactStreamImpl
 
allOf(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.EagerSimpleReactStream
 
allOf(Function<List<T>, R>) - Method in interface com.aol.simple.react.stream.traits.EagerSimpleReactStream
React and allOf allOf is a non-blocking equivalent of block.
allOf(Collector, Function<T, R>) - Method in interface com.aol.simple.react.stream.traits.EagerToQueue
 
AlwaysContinue - Class in com.aol.simple.react.async.subscription
 
AlwaysContinue() - Constructor for class com.aol.simple.react.async.subscription.AlwaysContinue
 
anyMatch(Predicate<? super T>) - Method in class com.aol.simple.react.stream.traits.FutureOps
Perform an asynchronous Any Match operation
anyMatch(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
anyOf(FastFuture...) - Static method in class com.aol.simple.react.async.future.FastFuture
 
anyOf(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
anyOf(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.EagerSimpleReactStream
React to the completion of any of the events in the previous stage.
apply(Supplier<U>) - Method in class com.aol.simple.react.stream.traits.operators.BatchBySize
 
apply(BiFunction<Long, TimeUnit, U>) - Method in class com.aol.simple.react.stream.traits.operators.BatchByTime
 
apply(BiFunction<Long, TimeUnit, U>) - Method in class com.aol.simple.react.stream.traits.operators.BatchByTimeAndSize
 
apply(Supplier<T>) - Method in class com.aol.simple.react.stream.traits.operators.Debounce
 
apply(Supplier<U>) - Method in class com.aol.simple.react.stream.traits.operators.OnePer
 
assureSimpleReactException(Throwable) - Static method in interface com.aol.simple.react.stream.traits.EagerSimpleReactStream
 
assureSimpleReactException(Throwable) - Static method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
 
async(Function<EagerReact, EagerFutureStream<T>>) - Method in interface com.aol.simple.react.mixins.EagerReactive
Generate a multi-threaded EagerFutureStream that executes all tasks via a task executor between each stage (unless sync operator invoked).
async(Function<LazyReact, LazyFutureStream<T>>) - Method in interface com.aol.simple.react.mixins.LazyReactive
Generate a multi-threaded LazyFutureStream that executes all tasks via a task executor between each stage (unless sync operator invoked).
async() - Method in class com.aol.simple.react.stream.lazy.LazyReact
Start any created Streams in asyncrhonous mode - that is tasks will be submited to an Executor to be run.
async() - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
async() - Method in interface com.aol.simple.react.stream.traits.EagerSimpleReactStream
 
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
 
autoOptimizeOff() - Method in class com.aol.simple.react.stream.lazy.LazyReact
Turn off automatic threading management.
autoOptimizeOn() - Method in class com.aol.simple.react.stream.lazy.LazyReact
Turn on automatic threading optimization.
averageDouble(ToDoubleFunction<T>) - Method in interface com.aol.simple.react.stream.traits.future.operators.DoubleOperators
Perform an asynchronous average operation
averageInt(ToIntFunction<T>) - Method in interface com.aol.simple.react.stream.traits.future.operators.IntOperators
Perform an asynchronous average operation
averageLong(ToLongFunction<T>) - Method in interface com.aol.simple.react.stream.traits.future.operators.LongOperators
Perform an asynchronous average operation
await() - Method in class com.aol.simple.react.async.future.FastFuture
 

B

BaseSimpleReact - Class in com.aol.simple.react.stream
 
BaseSimpleReact() - Constructor for class com.aol.simple.react.stream.BaseSimpleReact
 
BaseSimpleReact(Executor) - Constructor for class com.aol.simple.react.stream.BaseSimpleReact
 
batch(Function<Supplier<U>, Supplier<C>>) - 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<C>>) - 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<C>>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Batch elements into a Stream of collections with user defined function
batchBySize(int) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Batch the elements in this stream into Lists of specified size
batchBySize(int, Supplier<C>) - 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<C>) - 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<C>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Batch the elements in this stream into Collections of specified size The type of Collection is determined by the specified supplier
BatchBySize<U,C extends java.util.Collection<U>> - Class in com.aol.simple.react.stream.traits.operators
 
BatchBySize() - Constructor for class com.aol.simple.react.stream.traits.operators.BatchBySize
 
batchBySizeAndTime(int, long, TimeUnit) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
batchBySizeAndTime(int, long, TimeUnit) - Method in interface com.aol.simple.react.stream.traits.FutureStream
Batch the elements in the Stream by a combination of Size and Time If batch exceeds max size it will be split If batch exceeds max time it will be split Excludes Null values (neccessary for timeout handling)
batchBySizeAndTime(int, long, TimeUnit, Supplier<C>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
Batch the elements in the Stream by a combination of Size and Time If batch exceeds max size it will be split If batch exceeds max time it will be split Excludes Null values (neccessary for timeout handling)
batchBySizeAndTime(int, long, TimeUnit) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
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 This version uses locks - for a lock free implementation choose
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 Excludes Null values (neccessary for timeout handling)
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
BatchByTime<U> - Class in com.aol.simple.react.stream.traits.operators
 
BatchByTime() - Constructor for class com.aol.simple.react.stream.traits.operators.BatchByTime
 
BatchByTimeAndSize<U> - Class in com.aol.simple.react.stream.traits.operators
 
BatchByTimeAndSize() - Constructor for class com.aol.simple.react.stream.traits.operators.BatchByTimeAndSize
 
BatchingCollector<T> - Class in com.aol.simple.react.collectors.lazy
This class allows a Batch of completable futures to be processed before collecting their results, to increase parallelism.
BatchingCollector(MaxActive, BlockingStream<T>) - Constructor for class com.aol.simple.react.collectors.lazy.BatchingCollector
 
bind(EagerSimpleReactStream<U>, Function<U, SimpleReactStream<R>>) - Static method in interface com.aol.simple.react.stream.traits.EagerSimpleReactStream
flatMap / bind implementation that returns the correct type (SimpleReactStream)
block(Predicate<Status>) - Method in class com.aol.simple.react.blockers.Blocker
 
block(Function<FastFuture<T>, T>) - Method in class com.aol.simple.react.collectors.lazy.BatchingCollector
 
block(Function<FastFuture<T>, T>) - Method in class com.aol.simple.react.collectors.lazy.EmptyCollector
 
block(Function<FastFuture<T>, T>) - Method in interface com.aol.simple.react.collectors.lazy.LazyResultConsumer
 
block(Function<FastFuture<T>, T>) - Method in class com.aol.simple.react.collectors.lazy.SamplingCollector
 
block() - Method in interface com.aol.simple.react.stream.traits.BlockingStream
React and block
block(Collector<? super U, A, R>) - Method in interface com.aol.simple.react.stream.traits.BlockingStream
 
block(Predicate<Status>) - Method in interface com.aol.simple.react.stream.traits.EagerSimpleReactStream
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.EagerSimpleReactStream
 
blockAndExtract(Extractor) - Method in interface com.aol.simple.react.stream.traits.BlockingStream
Block until tasks complete and return a value determined by the extractor supplied.
blockAndExtract(Extractor, Predicate<Status>) - Method in interface com.aol.simple.react.stream.traits.BlockingStream
Block until tasks complete, or breakout conditions met and return a value determined by the extractor supplied.
Blocker<U> - Class in com.aol.simple.react.blockers
 
Blocker() - Constructor for class com.aol.simple.react.blockers.Blocker
 
BlockingStream<U> - Interface in com.aol.simple.react.stream.traits
 
BlockingStreamHelper - Class in com.aol.simple.react.stream.traits
 
BlockingStreamHelper() - Constructor for class com.aol.simple.react.stream.traits.BlockingStreamHelper
 
boundedNonBlockingQueue(int) - Static method in class com.aol.simple.react.async.factories.QueueFactories
Creates an async.Queue backed by an Agrona ManyToOneConcurrentArrayQueue bounded by specified queueSize Wait strategy used is NoWaitRetry by default for both Consumers and Producers (both Consumers and Producers will repeatedly retry until successful).
boundedPool(Collection<REACTOR>) - Static method in class com.aol.simple.react.threads.ReactPool
If all REACTORs are in use calling react will block.
boundedQueue(int) - Static method in class com.aol.simple.react.async.factories.QueueFactories
 
boundedWaitFree(int) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Use an Agrona ManyToOneConcurrentArrayQueue for the next operations (wait-free, mechanical sympathy).
build() - Method in interface com.aol.simple.react.async.factories.QueueFactory
 
build() - Method in class com.aol.simple.react.async.future.PipelineBuilder
 

C

cancel() - Method in interface com.aol.simple.react.reactivestreams.FutureStreamAsyncPublisher
 
cancel() - Method in interface com.aol.simple.react.reactivestreams.FutureStreamSynchronousPublisher
 
cancel() - Method in class com.aol.simple.react.stream.lazy.LazyFutureStreamImpl
Cancel the CompletableFutures in this stage of the stream
cancel() - Method in interface com.aol.simple.react.stream.traits.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
cancel() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
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.EagerSimpleReactStream
React capture While onFail is used for disaster recovery (when it is possible to recover) - capture is used to capture those occasions where the full pipeline has failed and is unrecoverable.
capture(Consumer<? extends Throwable>) - Method in interface com.aol.simple.react.stream.traits.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.LazySimpleReactStream
React capture While onFail is used for disaster recovery (when it is possible to recover) - capture is used to capture those occasions where the full pipeline has failed and is unrecoverable.
capture(Consumer<? extends Throwable>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
React capture While onFail is used for disaster recovery (when it is possible to recover) - capture is used to capture those occasions where the full pipeline has failed and is unrecoverable.
cast(Class<U>) - Method in interface com.aol.simple.react.stream.traits.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
 
clear() - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
clear() - Static method in class com.aol.simple.react.async.pipes.Pipes
 
clearFast() - Method in class com.aol.simple.react.async.future.FastFuture
 
close() - Method in interface com.aol.simple.react.async.Adapter
Close this adapter
close() - Method in class com.aol.simple.react.async.Queue
Close this Queue
close() - Method in class com.aol.simple.react.async.Signal
Close this Signal
close() - Method in class com.aol.simple.react.async.Topic
Close this Topic
close() - Method in class com.aol.simple.react.stream.CloseableIterator
 
close() - Method in class com.aol.simple.react.stream.lazy.LazyFutureStreamImpl
 
close() - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
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.subscription.AlwaysContinue
 
closeAll() - Method in class com.aol.simple.react.async.subscription.AlwaysContinue
 
closeAll(Queue) - Method in interface com.aol.simple.react.async.subscription.Continueable
 
closeAll() - Method in interface com.aol.simple.react.async.subscription.Continueable
 
closeAll(Queue) - Method in class com.aol.simple.react.async.subscription.Subscription
 
closeAll() - Method in class com.aol.simple.react.async.subscription.Subscription
 
closeAll() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
closeAndClear() - Method in class com.aol.simple.react.async.Queue
 
closed() - Method in class com.aol.simple.react.async.subscription.AlwaysContinue
 
closed() - Method in interface com.aol.simple.react.async.subscription.Continueable
 
closed() - Method in class com.aol.simple.react.async.subscription.Subscription
 
ClosedQueueException() - Constructor for exception com.aol.simple.react.async.Queue.ClosedQueueException
 
closeQueueIfFinished(Queue) - Method in class com.aol.simple.react.async.subscription.AlwaysContinue
 
closeQueueIfFinished(Queue) - Method in interface com.aol.simple.react.async.subscription.Continueable
 
closeQueueIfFinished(Queue) - Method in class com.aol.simple.react.async.subscription.Subscription
 
closeQueueIfFinishedStateless(Queue) - Method in class com.aol.simple.react.async.subscription.AlwaysContinue
 
closeQueueIfFinishedStateless(Queue) - Method in interface com.aol.simple.react.async.subscription.Continueable
 
closeQueueIfFinishedStateless(Queue) - Method in class com.aol.simple.react.async.subscription.Subscription
 
ClosingSpliterator<T> - Class in com.aol.simple.react.async
 
ClosingSpliterator(long, Supplier<T>, Continueable, Queue) - Constructor for class com.aol.simple.react.async.ClosingSpliterator
 
ClosingSpliterator(long, Supplier<T>, Continueable) - Constructor for class com.aol.simple.react.async.ClosingSpliterator
 
collect(Collector<? super U, A, R>) - Method in class com.aol.simple.react.stream.eager.EagerFutureStreamImpl
 
collect(Collector<? super U, A, R>) - Method in class com.aol.simple.react.stream.lazy.LazyFutureStreamImpl
 
collect(Collector<? super T, A, R>) - Method in class com.aol.simple.react.stream.traits.FutureOps
Asynchronously perform a Stream collection
collect(Supplier<R>, BiConsumer<R, ? super T>, BiConsumer<R, R>) - Method in class com.aol.simple.react.stream.traits.FutureOps
Asynchronously perform a Stream collection
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.async.factories - package com.aol.simple.react.async.factories
 
com.aol.simple.react.async.future - package com.aol.simple.react.async.future
 
com.aol.simple.react.async.future.pool - package com.aol.simple.react.async.future.pool
 
com.aol.simple.react.async.pipes - package com.aol.simple.react.async.pipes
 
com.aol.simple.react.async.subscription - package com.aol.simple.react.async.subscription
 
com.aol.simple.react.async.wait - package com.aol.simple.react.async.wait
 
com.aol.simple.react.blockers - package com.aol.simple.react.blockers
 
com.aol.simple.react.collectors.lazy - package com.aol.simple.react.collectors.lazy
 
com.aol.simple.react.config - package com.aol.simple.react.config
 
com.aol.simple.react.exceptions - package com.aol.simple.react.exceptions
 
com.aol.simple.react.extractors - package com.aol.simple.react.extractors
 
com.aol.simple.react.mixins - package com.aol.simple.react.mixins
 
com.aol.simple.react.monad - package com.aol.simple.react.monad
 
com.aol.simple.react.reactivestreams - package com.aol.simple.react.reactivestreams
 
com.aol.simple.react.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.stream.traits.future.operators - package com.aol.simple.react.stream.traits.future.operators
 
com.aol.simple.react.stream.traits.operators - package com.aol.simple.react.stream.traits.operators
 
com.aol.simple.react.threads - package com.aol.simple.react.threads
 
com.aol.simple.react.util - package com.aol.simple.react.util
 
combineLatest(EagerSimpleReactStream<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).
CompletedException - Exception in com.aol.simple.react.async.future
 
CompletedException(Object) - Constructor for exception com.aol.simple.react.async.future.CompletedException
 
completedFuture(T) - Static method in class com.aol.simple.react.async.future.FastFuture
 
concat(Stream<U>) - Method in class com.aol.simple.react.stream.LazyStreamWrapper
 
concat(Stream<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.
concat(U) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Concatenate two streams.
concat(U...) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Concatenate two streams.
ConfigurableStream<T,C> - Interface in com.aol.simple.react.stream.traits
 
construct(Stream) - Method in class com.aol.simple.react.stream.BaseSimpleReact
 
construct(Stream) - Method in class com.aol.simple.react.stream.eager.EagerReact
 
construct(Stream) - Method in class com.aol.simple.react.stream.lazy.LazyReact
 
construct(Stream) - Method in class com.aol.simple.react.stream.simple.SimpleReact
 
constructFutures(Stream<CompletableFuture<U>>) - Method in class com.aol.simple.react.stream.lazy.LazyReact
 
contains(Object) - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
containsAll(Collection) - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
Continuation - Class in com.aol.simple.react.stream.traits
 
Continuation() - Constructor for class com.aol.simple.react.stream.traits.Continuation
 
ContinuationStrategy - Interface in com.aol.simple.react.async
 
Continueable - Interface in com.aol.simple.react.async.subscription
 
control(Function<Supplier<U>, Supplier<U>>) - Method in interface com.aol.simple.react.stream.traits.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.EagerSimpleReactStream
Convert between an Lazy and Eager future stream, can be used to take advantages of each approach during a single 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
convertToEagerStream() - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Convert between an Lazy and Eager future stream, can be used to take advantages of each approach during a single Stream
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
copy(int) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
copy(int) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Copy this Stream the specified number of times
copySimpleReactStream(int) - Method in interface com.aol.simple.react.stream.traits.EagerSimpleReactStream
 
copySimpleReactStream(int) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
 
count() - Method in class com.aol.simple.react.stream.traits.FutureOps
Asynchronously perform a Stream count
count() - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
CPU - Static variable in class com.aol.simple.react.config.MaxActive
 
cpuReact - Static variable in class com.aol.simple.react.async.pipes.EagerReactors
 
cpuReact - Static variable in class com.aol.simple.react.async.pipes.LazyReactors
 
cpuStream() - Method in interface com.aol.simple.react.mixins.EagerReactive
 
cpuStream() - Method in interface com.aol.simple.react.mixins.LazyReactive
 
createMergeQueue() - Static method in class com.aol.simple.react.async.Queue
 
crossJoin(Stream<T>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Cross join 2 streams into one.
crossJoin(Stream<T>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
crossJoin(Stream<T>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Cross join 2 streams into one.
cycle() - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
UnsupportedOperation for EagerFutureStreams Requires ability to support infinite Streams
cycle() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Create a Stream that infinitely cycles this Stream
cycle(int) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Create a Stream that finitely cycles this Stream, provided number of times
cycleUntil(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Repeat in a Stream until specified predicate holds
cycleWhile(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Repeat in a Stream while specified predicate holds

D

debounce(long, TimeUnit) - Method in interface com.aol.simple.react.stream.traits.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.
Debounce<T> - Class in com.aol.simple.react.stream.traits.operators
 
Debounce() - Constructor for class com.aol.simple.react.stream.traits.operators.Debounce
 
defaultValue - Static variable in class com.aol.simple.react.stream.lazy.ParallelReductionConfig
 
DirectWaitStrategy<T> - Class in com.aol.simple.react.async.wait
Will try to access the queue once, and return the result directly from the Queue Effectively the same as calling queue.take() / queue.offer(T val)
DirectWaitStrategy() - Constructor for class com.aol.simple.react.async.wait.DirectWaitStrategy
 
disconnect(Stream<T>) - Method in class com.aol.simple.react.async.Topic
Topic will maintain a queue for each Subscribing Stream If a Stream is finished with a Topic it is good practice to disconnect from the Topic so messages will no longer be stored for that Stream
distinct() - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
distinct() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
done(FastFuture<T>) - Method in class com.aol.simple.react.async.future.pool.FuturePool
 
doOnEach(Function<U, U>) - Method in interface com.aol.simple.react.stream.traits.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.EagerSimpleReactStream
Applies a function to this phase independent on the main flow.
doOnEach(Function<U, U>) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
Applies a function to this phase independent on the main flow.
doOnEach(Function<U, U>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Applies a function to this phase independent on the main flow.
doOnEachSync(Function<U, U>) - Method in interface com.aol.simple.react.stream.traits.EagerSimpleReactStream
Applies a function to this phase independent on the main flow, continues on the currently executing thread.
doOnEachSync(Function<U, U>) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
Applies a function to this phase independent on the main flow, continues on the currently executing thread.
doOnEachSync(Function<U, U>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Applies a function to this phase independent on the main flow, continues on the currently executing thread.
DoubleOperators<T> - Interface in com.aol.simple.react.stream.traits.future.operators
 
drainTo(Collection) - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
drainTo(Collection, int) - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
drainToOrBlock() - Method in class com.aol.simple.react.async.Queue.QueueReader
 
duplicate() - Method in interface com.aol.simple.react.stream.traits.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 LazyFutureStream 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!
duplicateFutureStream() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 

E

EagerFutureStream<U> - Interface in com.aol.simple.react.stream.traits
Static Factory methods for Simple React Flows
eagerFutureStream(CompletableFuture<T>) - Static method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Create a 'free threaded' asynchronous stream that runs on the supplied CompletableFutures executor service (unless async operator invoked , in which it will switch to the common 'free' thread executor) Subsequent tasks will be executed synchronously unless the async() operator is invoked.
eagerFutureStream(CompletableFuture<T>...) - Static method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Create a 'free threaded' asynchronous stream that runs on a single thread (not current) The supplier will be executed asyncrhonously, subsequent tasks will be executed synchronously unless the async() operator is invoked.
eagerFutureStream(Stream<T>) - Static method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Wrap a Stream into a Sequential synchronous FutureStream that runs on the current thread
eagerFutureStream(Iterator<T>) - Static method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Wrap an Iterator into a FutureStream that runs on the current thread
EagerFutureStreamComprehender - Class in com.aol.simple.react.monad
Cyclops Monad Comprehender for EagerFutureStreams
EagerFutureStreamComprehender() - Constructor for class com.aol.simple.react.monad.EagerFutureStreamComprehender
 
eagerFutureStreamFrom(Stream<CompletableFuture<T>>) - Static method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Create a 'free threaded' asynchronous stream that runs on the supplied CompletableFutures executor service (unless async operator invoked , in which it will switch to the common 'free' thread executor) Subsequent tasks will be executed synchronously unless the async() operator is invoked.
eagerFutureStreamFromIterable(Iterable<T>) - Static method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Wrap an Iterable into a FutureStream that runs on the current thread
EagerFutureStreamFunctions - Class in com.aol.simple.react.stream.traits
 
EagerFutureStreamFunctions() - Constructor for class com.aol.simple.react.stream.traits.EagerFutureStreamFunctions
 
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
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(Executor, RetryExecutor, Boolean, Executor) - 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
 
EagerReactive - Interface in com.aol.simple.react.mixins
Mixin / Trait for Reactive behaviour via simple-react
EagerReactors - Class in com.aol.simple.react.async.pipes
 
EagerReactors() - Constructor for class com.aol.simple.react.async.pipes.EagerReactors
 
EagerSimpleReactStream<U> - Interface in com.aol.simple.react.stream.traits
 
EagerStreamWrapper - Class in com.aol.simple.react.stream
 
EagerStreamWrapper(List<CompletableFuture>) - Constructor for class com.aol.simple.react.stream.EagerStreamWrapper
 
EagerStreamWrapper(EagerStreamWrapper.AsyncList) - Constructor for class com.aol.simple.react.stream.EagerStreamWrapper
 
EagerStreamWrapper(Stream<CompletableFuture>) - Constructor for class com.aol.simple.react.stream.EagerStreamWrapper
 
EagerStreamWrapper(Stream<CompletableFuture>, Collector) - Constructor for class com.aol.simple.react.stream.EagerStreamWrapper
 
EagerStreamWrapper(CompletableFuture) - Constructor for class com.aol.simple.react.stream.EagerStreamWrapper
 
EagerToQueue<U> - Interface in com.aol.simple.react.stream.traits
 
elasticPool(Supplier<REACTOR>) - Static method in class com.aol.simple.react.threads.ReactPool
If all REACTORs are in use calling react will create a new REACTOR to handle the extra demand.
element() - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
empty() - Static method in class com.aol.simple.react.async.future.ExecutionPipeline
 
empty() - Static method in class com.aol.simple.react.async.future.FinalPipeline
 
empty() - Method in class com.aol.simple.react.monad.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
Create a sequential synchronous stream that runs on the current thread
empty() - Static method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Create an empty sequential synchronous stream that runs on the current thread
EmptyCollector<T> - Class in com.aol.simple.react.collectors.lazy
A collector that periodically joins active completablefutures but does not store the results
enqueue(K, V) - Method in interface com.aol.simple.react.mixins.EagerReactive
Add a value to an simple-react Async.Adapter (Queue / Topic /Signal) if present Returns the Adapter wrapped in an Optional
enqueue(K, V) - Method in interface com.aol.simple.react.mixins.LazyReactive
Add a value to an simple-react Async.Adapter (Queue / Topic /Signal) if present Returns the Adapter wrapped in an Optional
equals(Object) - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
essential(Consumer<FastFuture.OnComplete>) - Method in class com.aol.simple.react.async.future.FastFuture
Called at least once on complete
estimateSize() - Method in class com.aol.simple.react.async.ClosingSpliterator
 
estimateSize() - Method in class com.aol.simple.react.stream.InfiniteClosingSpliterator
 
estimateSize() - Method in class com.aol.simple.react.stream.InfiniteClosingSpliteratorFromIterator
 
exception - Variable in class com.aol.simple.react.async.future.FastFuture.OnComplete
 
exceptionally(Function<X, T>) - Method in class com.aol.simple.react.async.future.ExecutionPipeline
 
exceptionally - Variable in class com.aol.simple.react.async.future.FastFuture.OnComplete
 
exceptionally(Function<X, T>) - Method in class com.aol.simple.react.async.future.PipelineBuilder
 
ExceptionSoftener - Class in com.aol.simple.react.exceptions
 
ExceptionSoftener() - Constructor for class com.aol.simple.react.exceptions.ExceptionSoftener
 
ExceptionSoftener.singleton - Enum in com.aol.simple.react.exceptions
 
ExecutionPipeline - Class in com.aol.simple.react.async.future
 
ExecutionPipeline() - Constructor for class com.aol.simple.react.async.future.ExecutionPipeline
 
executors - Variable in class com.aol.simple.react.async.future.FinalPipeline
 
ExponentialBackofWaitStrategy<T> - Class in com.aol.simple.react.async.wait
 
ExponentialBackofWaitStrategy() - Constructor for class com.aol.simple.react.async.wait.ExponentialBackofWaitStrategy
 
extract(T) - Method in interface com.aol.simple.react.extractors.Extractor
 
Extractor<T,R> - Interface in com.aol.simple.react.extractors
Functional interface for extracting results from a blocking call.
Extractors - Class in com.aol.simple.react.extractors
Default extractors for determining return values from blocking stage.
Extractors() - Constructor for class com.aol.simple.react.extractors.Extractors
 

F

FastFuture<T> - Class in com.aol.simple.react.async.future
 
FastFuture() - Constructor for class com.aol.simple.react.async.future.FastFuture
 
FastFuture(FinalPipeline, Consumer<FastFuture<T>>) - Constructor for class com.aol.simple.react.async.future.FastFuture
 
FastFuture(FinalPipeline, int) - Constructor for class com.aol.simple.react.async.future.FastFuture
 
FastFuture.OnComplete - Class in com.aol.simple.react.async.future
 
fillInStackTrace() - Method in exception com.aol.simple.react.async.future.CompletedException
 
fillInStackTrace() - Method in exception com.aol.simple.react.async.Queue.ClosedQueueException
 
fillInStackTrace() - Method in exception com.aol.simple.react.async.Queue.QueueTimeoutException
 
fillInStackTrace() - Method in exception com.aol.simple.react.exceptions.FilteredExecutionPathException
 
fillInStackTrace() - Method in exception com.aol.simple.react.exceptions.SimpleReactCompletionException
 
fillInStackTrace() - Method in exception com.aol.simple.react.exceptions.SimpleReactProcessingException
 
filter(EagerFutureStream, Predicate) - Method in class com.aol.simple.react.monad.EagerFutureStreamComprehender
 
filter(LazyFutureStream, Predicate) - Method in class com.aol.simple.react.monad.LazyFutureStreamComprehender
 
filter(EagerSimpleReactStream, 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.EagerSimpleReactStream
Removes elements that do not match the supplied predicate from the dataflow
filter(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.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.LazySimpleReactStream
Removes elements that do not match the supplied predicate from the dataflow
filter(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Removes elements that do not match the supplied predicate from the dataflow
FilteredExecutionPathException - Exception in com.aol.simple.react.exceptions
 
FilteredExecutionPathException() - Constructor for exception com.aol.simple.react.exceptions.FilteredExecutionPathException
 
filterSync(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.EagerSimpleReactStream
Synchronous filtering operation Removes elements that do not match the supplied predicate from the dataflow
filterSync(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
Synchronous filtering operation Removes elements that do not match the supplied predicate from the dataflow
filterSync(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Synchronous filtering operation Removes elements that do not match the supplied predicate from the dataflow
FinalPipeline - Class in com.aol.simple.react.async.future
 
FinalPipeline() - Constructor for class com.aol.simple.react.async.future.FinalPipeline
 
findAny() - Method in class com.aol.simple.react.stream.traits.FutureOps
Perform an asynchronous findAny operation
findAny() - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
findFirst() - Method in class com.aol.simple.react.stream.traits.FutureOps
Perform an asynchronous findAny operation
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 class com.aol.simple.react.stream.traits.EagerFutureStreamFunctions
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
firstRecover - Variable in class com.aol.simple.react.async.future.FinalPipeline
 
firstValue() - Method in class com.aol.simple.react.stream.traits.FutureOps
Perform an asynchronous findAny operation
firstValue() - Method in interface com.aol.simple.react.stream.traits.FutureStream
int first = LazyFutureStream.of(1,2,3,4) .firstValue(); //first is 1
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(EagerSimpleReactStream, 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.EagerSimpleReactStream
Allows aggregate values in a Stream to be flatten into a single Stream.
flatMap(Function<? super U, ? extends Stream<? extends R>>) - Method in interface com.aol.simple.react.stream.traits.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.LazySimpleReactStream
Allows aggregate values in a Stream to be flatten into a single Stream.
flatMap(Function<? super U, ? extends Stream<? extends R>>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Allows aggregate values in a Stream to be flatten into a single Stream.
flatMapCompletableFuture(Function<U, CompletableFuture<R>>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Perform a flatMap operation where the CompletableFuture type returned is flattened from the resulting Stream If in async mode this operation is performed asyncrhonously If in sync mode this operation is performed synchronously
flatMapCompletableFuture(Function<U, CompletableFuture<R>>) - Method in interface com.aol.simple.react.stream.traits.EagerSimpleReactStream
Perform a flatMap operation where the CompletableFuture type returned is flattened from the resulting Stream If in async mode this operation is performed asyncrhonously If in sync mode this operation is performed synchronously
flatMapCompletableFuture(Function<U, CompletableFuture<R>>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Perform a flatMap operation where the CompletableFuture type returned is flattened from the resulting Stream If in async mode this operation is performed asyncrhonously If in sync mode this operation is performed synchronously
flatMapCompletableFuture(Function<U, CompletableFuture<R>>) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
Perform a flatMap operation where the CompletableFuture type returned is flattened from the resulting Stream If in async mode this operation is performed asyncrhonously If in sync mode this operation is performed synchronously
flatMapCompletableFuture(Function<U, CompletableFuture<R>>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Perform a flatMap operation where the CompletableFuture type returned is flattened from the resulting Stream If in async mode this operation is performed asyncrhonously If in sync mode this operation is performed synchronously
flatMapCompletableFutureSync(Function<U, CompletableFuture<R>>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Perform a flatMap operation where the CompletableFuture type returned is flattened from the resulting Stream This operation is performed synchronously
flatMapCompletableFutureSync(Function<U, CompletableFuture<R>>) - Method in interface com.aol.simple.react.stream.traits.EagerSimpleReactStream
Perform a flatMap operation where the CompletableFuture type returned is flattened from the resulting Stream This operation is performed synchronously
flatMapCompletableFutureSync(Function<U, CompletableFuture<R>>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Perform a flatMap operation where the CompletableFuture type returned is flattened from the resulting Stream This operation is performed synchronously
flatMapCompletableFutureSync(Function<U, CompletableFuture<R>>) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
Perform a flatMap operation where the CompletableFuture type returned is flattened from the resulting Stream This operation is performed synchronously
flatMapCompletableFutureSync(Function<U, CompletableFuture<R>>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Perform a flatMap operation where the CompletableFuture type returned is flattened from the resulting Stream This operation is performed synchronously
flatMapToDouble(Function<? super U, ? extends DoubleStream>) - Method in interface com.aol.simple.react.stream.traits.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
 
foldLeft(U, BiFunction<U, ? super T, U>) - Method in class com.aol.simple.react.stream.traits.FutureOps
Perform an asynchronous foldLeft operation
foldRight(U, BiFunction<? super T, U, U>) - Method in class com.aol.simple.react.stream.traits.FutureOps
Perform an asynchronous foldRight operation
forEach(Consumer) - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
forEach(Consumer<? super T>, Function<FastFuture, T>) - Method in class com.aol.simple.react.collectors.lazy.IncrementalReducer
 
forEach(Consumer<? super U>) - Method in interface com.aol.simple.react.stream.traits.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<FastFuture<T>>, Consumer<? super T>, Function<FastFuture, T>) - Method in class com.aol.simple.react.collectors.lazy.IncrementalReducer
 
forwardErrors(Consumer<Throwable>) - Method in interface com.aol.simple.react.reactivestreams.FutureStreamAsyncPublisher
 
forwardErrors(Consumer<Throwable>) - Method in interface com.aol.simple.react.reactivestreams.FutureStreamSynchronousPublisher
 
forwardErrors(Consumer<Throwable>) - Method in class com.aol.simple.react.stream.lazy.LazyFutureStreamImpl
 
from(Iterator<U>) - Method in class com.aol.simple.react.stream.BaseSimpleReact
Start a reactive flow from a JDK Iterator
from(Collection<R>) - Method in class com.aol.simple.react.stream.BaseSimpleReact
Start a reactive flow from a Collection using an Iterator
from(Stream<U>) - Method in class com.aol.simple.react.stream.BaseSimpleReact
Start a reactive dataflow from a stream.
from(IntStream) - Method in class com.aol.simple.react.stream.BaseSimpleReact
Start a reactive dataflow from a stream.
from(DoubleStream) - Method in class com.aol.simple.react.stream.BaseSimpleReact
Start a reactive dataflow from a stream.
from(LongStream) - Method in class com.aol.simple.react.stream.BaseSimpleReact
Start a reactive dataflow from a stream.
from(CompletableFuture<U>) - Method in class com.aol.simple.react.stream.BaseSimpleReact
 
from(CompletableFuture<U>...) - Method in class com.aol.simple.react.stream.BaseSimpleReact
 
from(Stream<U>) - Method in class com.aol.simple.react.stream.eager.EagerReact
 
from(IntStream) - Method in class com.aol.simple.react.stream.eager.EagerReact
 
from(DoubleStream) - Method in class com.aol.simple.react.stream.eager.EagerReact
 
from(LongStream) - Method in class com.aol.simple.react.stream.eager.EagerReact
 
from(Iterator<U>) - Method in class com.aol.simple.react.stream.eager.EagerReact
Start a LazyFutureStream from a JDK Iterator
from(Collection<R>) - Method in class com.aol.simple.react.stream.eager.EagerReact
Start a EagerFutureStream from a Collection
from(CompletableFuture<U>) - Method in class com.aol.simple.react.stream.eager.EagerReact
 
from(CompletableFuture<U>...) - Method in class com.aol.simple.react.stream.eager.EagerReact
 
from(CompletableFuture<U>) - Method in class com.aol.simple.react.stream.lazy.LazyReact
 
from(CompletableFuture<U>...) - Method in class com.aol.simple.react.stream.lazy.LazyReact
 
from(Stream<U>) - Method in class com.aol.simple.react.stream.lazy.LazyReact
 
from(IntStream) - Method in class com.aol.simple.react.stream.lazy.LazyReact
 
from(DoubleStream) - Method in class com.aol.simple.react.stream.lazy.LazyReact
 
from(LongStream) - Method in class com.aol.simple.react.stream.lazy.LazyReact
 
from(Iterator<U>) - Method in class com.aol.simple.react.stream.lazy.LazyReact
Start a LazyFutureStream from a JDK Iterator
from(Collection<R>) - Method in class com.aol.simple.react.stream.lazy.LazyReact
Start a LazyFutureStream from a Collection
fromCompletableFuture(CompletableFuture<T>) - Static method in class com.aol.simple.react.async.future.FastFuture
 
fromIterable(Iterable<U>) - Method in class com.aol.simple.react.stream.BaseSimpleReact
Start a reactive flow from a JDK Iterator
fromIterable(Iterable<U>) - Method in class com.aol.simple.react.stream.eager.EagerReact
 
fromIterable(Iterable<U>) - Method in class com.aol.simple.react.stream.lazy.LazyReact
 
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.EagerSimpleReactStream
 
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.EagerSimpleReactStream
 
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
 
fromStreamAsync(Stream<CompletableFuture<U>>) - Method in class com.aol.simple.react.stream.eager.EagerReact
 
fromStreamCompletableFutureReplace(Stream<CompletableFuture<R>>) - Method in interface com.aol.simple.react.stream.traits.EagerSimpleReactStream
 
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.EagerSimpleReactStream
Construct a SimpleReactStream from provided Stream of CompletableFutures
fromStreamOfFutures(Stream<FastFuture<R>>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
functions - Variable in class com.aol.simple.react.async.future.FinalPipeline
 
futureOperations() - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
futureOperations(Executor) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
FutureOps<T> - Class in com.aol.simple.react.stream.traits
 
FutureOps() - Constructor for class com.aol.simple.react.stream.traits.FutureOps
 
FuturePool - Class in com.aol.simple.react.async.future.pool
Single consumer / multiple producer future pool
FuturePool() - Constructor for class com.aol.simple.react.async.future.pool.FuturePool
 
FutureStream<U> - Interface in com.aol.simple.react.stream.traits
 
FutureStreamAsyncPublisher<T> - Interface in com.aol.simple.react.reactivestreams
Reactive Streams publisher that uses a separate thread (non-calling thread) to publish on
FutureStreamSubscriber<T> - Class in com.aol.simple.react.reactivestreams
Create a LazyFutureStream Subscriber to use
FutureStreamSubscriber() - Constructor for class com.aol.simple.react.reactivestreams.FutureStreamSubscriber
 
FutureStreamSynchronousPublisher<T> - Interface in com.aol.simple.react.reactivestreams
Reactive Streams publisher, that publishes on the calling thread

G

generate() - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Generate an infinite Stream of null values that runs on the current thread
generate(T) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Generate an infinite Stream of given value that runs on the current thread
generate(Supplier<T>) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Generate an infinite Stream of value returned from Supplier that runs on the current thread
get(K) - Static method in class com.aol.simple.react.async.pipes.Pipes
 
get() - Method in class com.aol.simple.react.async.Queue
 
getAllCompleted() - Method in class com.aol.simple.react.stream.Status
 
getAllResults() - Method in class com.aol.simple.react.collectors.lazy.BatchingCollector
 
getAllResults() - Method in class com.aol.simple.react.collectors.lazy.EmptyCollector
 
getAllResults() - Method in interface com.aol.simple.react.collectors.lazy.LazyResultConsumer
 
getAllResults() - Method in class com.aol.simple.react.collectors.lazy.SamplingCollector
 
getCompleted() - Method in class com.aol.simple.react.stream.Status
 
getElapsedMillis() - Method in class com.aol.simple.react.stream.Status
 
getElapsedNanos() - Method in class com.aol.simple.react.stream.Status
 
getElapsedNanoseconds() - Method in class com.aol.simple.react.util.SimpleTimer
 
getErrorHandler() - Method in interface com.aol.simple.react.stream.traits.BlockingStream
 
getErrorHandler() - Method in interface com.aol.simple.react.stream.traits.ConfigurableStream
 
getErrorHandler() - Method in interface com.aol.simple.react.stream.traits.LazyStream
 
getErrors() - Method in class com.aol.simple.react.stream.Status
 
getExec() - Method in interface com.aol.simple.react.stream.traits.future.operators.HasExec
 
getExecutor() - Method in class com.aol.simple.react.stream.BaseSimpleReact
 
getInput() - Method in class com.aol.simple.react.stream.pushable.AbstractPushableStream
 
getInput() - Method in class com.aol.simple.react.stream.pushable.MultiplePushableStreamsBuilder
 
getLastActive() - Method in interface com.aol.simple.react.reactivestreams.FutureStreamAsyncPublisher
 
getLastActive() - Method in interface com.aol.simple.react.reactivestreams.FutureStreamSynchronousPublisher
 
getLastActive() - Method in interface com.aol.simple.react.stream.traits.BlockingStream
 
getLastActive() - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
getLastActive() - Method in interface com.aol.simple.react.stream.traits.EagerSimpleReactStream
 
getLastActive() - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
getLastActive() - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
 
getLastActive() - Method in interface com.aol.simple.react.stream.traits.LazyStream
 
getLastActive() - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
getLazyCollector() - Method in interface com.aol.simple.react.stream.traits.LazyStream
 
getLazyExecutor() - Static method in class com.aol.simple.react.stream.ThreadPools
 
getMaxActive() - Method in interface com.aol.simple.react.stream.traits.LazyStream
 
getParallelReduction() - Method in interface com.aol.simple.react.stream.traits.LazyStream
 
getPopulator() - Method in class com.aol.simple.react.stream.eager.EagerFutureStreamImpl
 
getPopulator() - Method in class com.aol.simple.react.stream.lazy.LazyFutureStreamImpl
 
getPopulator() - Method in interface com.aol.simple.react.stream.traits.LazyToQueue
 
getPublisherExecutor() - Method in interface com.aol.simple.react.reactivestreams.FutureStreamAsyncPublisher
 
getQueueFactory() - Method in interface com.aol.simple.react.stream.traits.EagerToQueue
 
getQueueFactory() - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
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
 
getSimpleReact() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
getSimpleReact() - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
getSizeSignal() - Method in class com.aol.simple.react.async.Topic
 
getStandard() - Static method in class com.aol.simple.react.stream.ThreadPools
 
getStandardRetry() - Static method in class com.aol.simple.react.stream.ThreadPools
 
getStream() - Method in class com.aol.simple.react.stream.pushable.AbstractPushableStream
 
getStream() - Method in interface com.aol.simple.react.stream.traits.future.operators.HasStream
 
getSubscription() - Method in interface com.aol.simple.react.stream.traits.EagerSimpleReactStream
 
getSubscription() - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
getSubscription() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
getSubscription() - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
 
getSubscription() - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
getTargetClass() - Method in class com.aol.simple.react.monad.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
 
getTaskExecutor() - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
getTaskExecutor() - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
getTotal() - Method in class com.aol.simple.react.stream.Status
 
getValue() - Method in exception com.aol.simple.react.exceptions.SimpleReactFailedStageException
 
groupBy(Function<? super T, ? extends K>) - Method in class com.aol.simple.react.stream.traits.FutureOps
Perform an asyncrhonous groupBy operation
groupBy(Function<? super T, ? extends K>, Collector<? super T, A, D>) - Method in class com.aol.simple.react.stream.traits.FutureOps
Perform an asyncrhonous groupBy operation
groupBy(Function<? super T, ? extends K>, Supplier<M>, Collector<? super T, A, D>) - Method in class com.aol.simple.react.stream.traits.FutureOps
Perform an asyncrhonous groupBy operation

H

handleContinuation() - Method in interface com.aol.simple.react.async.ContinuationStrategy
 
handleContinuation() - Method in class com.aol.simple.react.async.SingleContinuation
 
handleContinuation() - Method in class com.aol.simple.react.async.StreamOfContinuations
 
handleExceptions(Function<U, R>) - Static method in interface com.aol.simple.react.stream.traits.EagerSimpleReactStream
 
handleExceptions(Function<U, R>) - Static method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
 
hasCapacity(int) - Method in class com.aol.simple.react.collectors.lazy.EmptyCollector
 
HasExec - Interface in com.aol.simple.react.stream.traits.future.operators
 
hashCode() - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
hasNext() - Method in class com.aol.simple.react.stream.CloseableIterator
 
HasStream<T> - Interface in com.aol.simple.react.stream.traits.future.operators
 

I

IncrementalReducer<T> - Class in com.aol.simple.react.collectors.lazy
Perform incremental (optionally parallel) reduction on a stream
IncrementalReducer() - Constructor for class com.aol.simple.react.collectors.lazy.IncrementalReducer
 
InfiniteClosingSpliterator<T> - Class in com.aol.simple.react.stream
 
InfiniteClosingSpliterator(long, Supplier<T>, Continueable, Queue) - Constructor for class com.aol.simple.react.stream.InfiniteClosingSpliterator
 
InfiniteClosingSpliterator(long, Supplier<T>, Continueable) - Constructor for class com.aol.simple.react.stream.InfiniteClosingSpliterator
 
InfiniteClosingSpliteratorFromIterator<T> - Class in com.aol.simple.react.stream
 
InfiniteClosingSpliteratorFromIterator(long, Iterator<T>, Continueable) - Constructor for class com.aol.simple.react.stream.InfiniteClosingSpliteratorFromIterator
 
InfiniteProcessingException - Exception in com.aol.simple.react.stream
 
InfiniteProcessingException(String) - Constructor for exception com.aol.simple.react.stream.InfiniteProcessingException
 
injectFutures() - Method in class com.aol.simple.react.stream.LazyStreamWrapper
 
innerJoin(Stream<T>, BiPredicate<U, T>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Inner join 2 streams into one.
innerJoin(Stream<T>, BiPredicate<U, T>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
innerJoin(Stream<T>, BiPredicate<U, T>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Inner join 2 streams into one.
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.
IntOperators<T> - Interface in com.aol.simple.react.stream.traits.future.operators
 
IO - Static variable in class com.aol.simple.react.config.MaxActive
 
ioReact - Static variable in class com.aol.simple.react.async.pipes.EagerReactors
 
ioReact - Static variable in class com.aol.simple.react.async.pipes.LazyReactors
 
ioStream() - Method in interface com.aol.simple.react.mixins.EagerReactive
 
ioStream() - Method in interface com.aol.simple.react.mixins.LazyReactive
 
isAsync() - Method in class com.aol.simple.react.stream.BaseSimpleReact
 
isAsync() - Method in class com.aol.simple.react.stream.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
 
isAsync() - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
isAsync() - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
isDataPresent() - Method in exception com.aol.simple.react.async.Queue.ClosedQueueException
 
isEmpty() - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
isOpen() - Method in class com.aol.simple.react.async.Queue
 
isOpen() - Method in class com.aol.simple.react.async.Queue.QueueReader
 
isParallel() - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
isSequential() - Method in class com.aol.simple.react.async.future.ExecutionPipeline
 
isSequential() - Method in class com.aol.simple.react.async.future.PipelineBuilder
 
isSequential() - Method in class com.aol.simple.react.stream.LazyStreamWrapper
 
isUseCommon() - Static method in class com.aol.simple.react.stream.ThreadPools
 
iterate(T, UnaryOperator<T>) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
iterateInfinitely(U, UnaryOperator<U>) - Method in class com.aol.simple.react.stream.lazy.LazyReact
Iterate infinitely using the supplied seed and function
iterator() - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
iterator() - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
iterator() - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 

J

JDKReactiveStreamsPublisher<T> - Class in com.aol.simple.react.reactivestreams
ReactiveStreams publisher for standard Java 8 Stream implementations including java.util.stream.Stream jool.Seq cyclops.SequenceM This provides both Asynchronous (external thread) and Synchronous (calling thread) publishing
JDKReactiveStreamsPublisher() - Constructor for class com.aol.simple.react.reactivestreams.JDKReactiveStreamsPublisher
 
JDKReactiveStreamsSubscriber<T> - Class in com.aol.simple.react.reactivestreams
ReactiveStreams subscriber for standard Java 8 Stream implementations including
JDKReactiveStreamsSubscriber() - Constructor for class com.aol.simple.react.reactivestreams.JDKReactiveStreamsSubscriber
 
jitter(long) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Introduce a random delay between events in a stream Can be used to prevent behaviour synchronizing within a system EagerFutureStreams will batch results before jittering For a better implementation see @see LazyFutureStream#jitter(long)
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() - Method in class com.aol.simple.react.async.future.FastFuture
Join which can be called exactly once!
join(EagerSimpleReactStream<SimpleReactStream<U>>) - Static method in interface com.aol.simple.react.stream.traits.EagerSimpleReactStream
flatten nested SimpleReactStreams
join(CharSequence) - Method in class com.aol.simple.react.stream.traits.FutureOps
 
join() - Method in class com.aol.simple.react.stream.traits.FutureOps
Perform an asynchronous join operation
join(CharSequence, CharSequence, CharSequence) - Method in class com.aol.simple.react.stream.traits.FutureOps
Perform an asynchronous join operation

L

last() - Static method in class com.aol.simple.react.extractors.Extractors
 
last() - Method in interface com.aol.simple.react.stream.traits.BlockingStream
Block until all results received.
lastActiveArray(EagerStreamWrapper) - Static method in interface com.aol.simple.react.stream.traits.EagerSimpleReactStream
 
lastValue() - Method in class com.aol.simple.react.stream.traits.FutureOps
 
LazyFutureStream<U> - Interface in com.aol.simple.react.stream.traits
Lazy Stream Factory methods
lazyFutureStream(CompletableFuture<T>) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Create a 'free threaded' asynchronous stream that runs on the supplied CompletableFutures executor service (unless async operator invoked , in which it will switch to the common 'free' thread executor) Subsequent tasks will be executed synchronously unless the async() operator is invoked.
lazyFutureStream(CompletableFuture<T>...) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Create a 'free threaded' asynchronous stream that runs on a single thread (not current) The supplier will be executed asyncrhonously, subsequent tasks will be executed synchronously unless the async() operator is invoked.
lazyFutureStream(Stream<T>) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Wrap a Stream into a FutureStream that runs on the current thread
lazyFutureStream(Iterator<T>) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Wrap an Iterator into a FutureStream that runs on the current thread
LazyFutureStreamComprehender - Class in com.aol.simple.react.monad
Cyclops Monad Comprehender for LazyFutureStreams
LazyFutureStreamComprehender() - Constructor for class com.aol.simple.react.monad.LazyFutureStreamComprehender
 
lazyFutureStreamFrom(Stream<CompletableFuture<T>>) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Create a 'free threaded' asynchronous stream that runs on the supplied CompletableFutures executor service (unless async operator invoked , in which it will switch to the common 'free' thread executor) Subsequent tasks will be executed synchronously unless the async() operator is invoked.
lazyFutureStreamFromIterable(Iterable<T>) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Wrap an Iterable into a FutureStream that runs on the current thread
LazyFutureStreamImpl<U> - Class in com.aol.simple.react.stream.lazy
 
LazyFutureStreamImpl(LazyReact, Stream<U>) - Constructor for class com.aol.simple.react.stream.lazy.LazyFutureStreamImpl
 
LazyReact - Class in com.aol.simple.react.stream.lazy
Builder class for LazyFutureStreams react methods - submit Suppliers to task executor of methods - build Streams directly from data
LazyReact() - Constructor for class com.aol.simple.react.stream.lazy.LazyReact
Construct a LazyReact builder using standard thread pool.
LazyReact(Executor) - Constructor for class com.aol.simple.react.stream.lazy.LazyReact
Construct a LazyReact builder with provided Executor
LazyReact(int, int) - Constructor for class com.aol.simple.react.stream.lazy.LazyReact
LazyReact builder with a new TaskExecutor with threads determined by threadPoolSize Max concurrent tasks is determined by concurrency
LazyReact(Executor, RetryExecutor, Boolean, MaxActive, Executor, boolean, boolean, boolean) - Constructor for class com.aol.simple.react.stream.lazy.LazyReact
 
LazyReact(Executor, AsyncRetryExecutor, boolean, MaxActive) - Constructor for class com.aol.simple.react.stream.lazy.LazyReact
 
lazyReact - Static variable in class com.aol.simple.react.threads.ParallelElasticPools
 
lazyReact - Static variable in class com.aol.simple.react.threads.SequentialElasticPools
 
LazyReactive - Interface in com.aol.simple.react.mixins
Mixin / Trait for Reactive behaviour via simple-react
LazyReactors - Class in com.aol.simple.react.async.pipes
 
LazyReactors() - Constructor for class com.aol.simple.react.async.pipes.LazyReactors
 
LazyResultConsumer<T> - Interface in com.aol.simple.react.collectors.lazy
Interface that defines the rules for Collecting results from Infinite SimpleReact Streams
LazySimpleReactStream<U> - Interface in com.aol.simple.react.stream.traits
 
LazyStream<U> - Interface in com.aol.simple.react.stream.traits
 
LazyStreamWrapper<U> - Class in com.aol.simple.react.stream
 
LazyStreamWrapper(Stream, LazyReact) - Constructor for class com.aol.simple.react.stream.LazyStreamWrapper
 
LazyToQueue<U> - Interface in com.aol.simple.react.stream.traits
 
leftOuterJoin(Stream<T>, BiPredicate<U, T>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Left outer join 2 streams into one.
leftOuterJoin(Stream<T>, BiPredicate<U, T>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
leftOuterJoin(Stream<T>, BiPredicate<U, T>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Left outer join 2 streams into one.
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
 
liftOptional() - Method in class com.aol.simple.react.stream.traits.operators.BatchBySize
 
liftOptional() - Method in class com.aol.simple.react.stream.traits.operators.BatchByTime
 
liftOptional() - Method in class com.aol.simple.react.stream.traits.operators.BatchByTimeAndSize
 
liftOptional() - Method in class com.aol.simple.react.stream.traits.operators.Debounce
 
liftOptional() - Method in class com.aol.simple.react.stream.traits.operators.OnePer
 
limit(long) - Method in interface com.aol.simple.react.stream.traits.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
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.EagerStreamWrapper
 
LongOperators<T> - Interface in com.aol.simple.react.stream.traits.future.operators
 

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(EagerSimpleReactStream, 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
 
markComplete() - Method in class com.aol.simple.react.async.future.FastFuture
 
max(Comparator<? super T>) - Method in class com.aol.simple.react.stream.traits.FutureOps
Perform an asyncrhonous min operation
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.
maxBy(Function<T, U>) - Method in class com.aol.simple.react.stream.traits.FutureOps
Asynchronously capture the maximum value in this stream using the provided function
maxDouble(ToDoubleFunction<T>) - Method in interface com.aol.simple.react.stream.traits.future.operators.DoubleOperators
Perform an asynchronous max operation
maxInt(ToIntFunction<T>) - Method in interface com.aol.simple.react.stream.traits.future.operators.IntOperators
Perform an asynchronous max operation
maxLong(ToLongFunction<T>) - Method in interface com.aol.simple.react.stream.traits.future.operators.LongOperators
Perform an asynchronous max operation
merge(EagerSimpleReactStream<U>...) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
merge(EagerSimpleReactStream<U>...) - Method in interface com.aol.simple.react.stream.traits.EagerSimpleReactStream
 
merge(EagerSimpleReactStream, EagerSimpleReactStream) - Static method in interface com.aol.simple.react.stream.traits.EagerSimpleReactStream
Merge this reactive dataflow with another - recommended for merging different types.
mergeLatest(LazyFutureStream<?>...) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Merges this stream and the supplied Streams into a single Stream where the next value is the next returned across any of the involved Streams.
mergeMultiple(EagerFutureStream...) - Static method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Merge two reactive dataflows with one and another.
min(Comparator<? super T>) - Method in class com.aol.simple.react.stream.traits.FutureOps
Perform an asyncrhonous min operation
min(Comparator<? super U>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
minBy(Function<T, U>) - Method in class com.aol.simple.react.stream.traits.FutureOps
Asynchronously capture the minimum value in this stream using the provided function
minDouble(ToDoubleFunction<T>) - Method in interface com.aol.simple.react.stream.traits.future.operators.DoubleOperators
Perform an asynchronous min operation
minInt(ToIntFunction<T>) - Method in interface com.aol.simple.react.stream.traits.future.operators.IntOperators
Perform an asynchronous min operation
minLong(ToLongFunction<T>) - Method in interface com.aol.simple.react.stream.traits.future.operators.LongOperators
Perform an asynchronous min operation
MISSING_VALUE - Static variable in class com.aol.simple.react.stream.MissingValue
 
MissingValue - Class in com.aol.simple.react.stream
 
MissingValue() - Constructor for class com.aol.simple.react.stream.MissingValue
 
multiple() - Method in class com.aol.simple.react.stream.pushable.PushableStreamBuilder
 
MultiplePushableStreamsBuilder<T> - Class in com.aol.simple.react.stream.pushable
Build Streams that stream data from the topic instance

N

next(Supplier<FastFuture<T>>) - Method in class com.aol.simple.react.async.future.pool.FuturePool
 
next() - Method in class com.aol.simple.react.async.Queue.QueueReader
 
next() - Method in class com.aol.simple.react.stream.CloseableIterator
 
nextReactor() - Method in class com.aol.simple.react.threads.ReactPool
 
NIL() - Constructor for class com.aol.simple.react.async.Queue.NIL
 
NILL - Static variable in class com.aol.simple.react.async.Queue
 
noneMatch(Predicate<? super T>) - Method in class com.aol.simple.react.stream.traits.FutureOps
Perform an asynchronous Any Match operation
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
 
NoWaitRetry<T> - Class in com.aol.simple.react.async.wait
Repeatedly retry to take or offer element to Queue if full or data unavailable
NoWaitRetry() - Constructor for class com.aol.simple.react.async.wait.NoWaitRetry
 
NULL - Static variable in class com.aol.simple.react.stream.traits.NullValue
 
NullValue - Class in com.aol.simple.react.stream.traits
 
NullValue() - Constructor for class com.aol.simple.react.stream.traits.NullValue
 

O

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

P

parallel() - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
parallel(U...) - Static method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Construct an EagerFutureStream Stream from specified array, that will run in parallel on the common Parallel executor service (by default the Common ForkJoinPool) see ThreadPools#setUseCommon to change to a different pool
parallel() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
parallel(U...) - Static method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Construct an parallel LazyFutureStream from specified array, using the configured standard parallel thread pool.
parallel(U...) - Static method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Construct an SimpleReactStream from specified array, that will run in parallel on the common Parallel executor service (by default the Common ForkJoinPool) see ThreadPools#setUseCommon to change to a different pool
parallelBuilder() - Static method in class com.aol.simple.react.stream.eager.EagerReact
 
parallelBuilder(int) - Static method in class com.aol.simple.react.stream.eager.EagerReact
Construct a new EagerReact builder, with a new task executor and retry executor with configured number of threads
parallelBuilder() - Static method in class com.aol.simple.react.stream.lazy.LazyReact
 
parallelBuilder(int) - Static method in class com.aol.simple.react.stream.lazy.LazyReact
Construct a new LazyReact builder, with a new task executor and retry executor with configured number of threads
parallelBuilder() - Static method in class com.aol.simple.react.stream.simple.SimpleReact
 
parallelBuilder(int) - Static method in class com.aol.simple.react.stream.simple.SimpleReact
Construct a new SimpleReact builder, with a new task executor and retry executor with configured number of threads
parallelCommonBuilder() - Static method in class com.aol.simple.react.stream.eager.EagerReact
 
parallelCommonBuilder() - Static method in class com.aol.simple.react.stream.lazy.LazyReact
 
parallelCommonBuilder() - Static method in class com.aol.simple.react.stream.simple.SimpleReact
 
ParallelElasticPools - Class in com.aol.simple.react.threads
A ReactPool of each type for parallel Streams Thread pool will be sized to number of processors
ParallelElasticPools() - Constructor for class com.aol.simple.react.threads.ParallelElasticPools
 
parallelism(int) - Method in class com.aol.simple.react.RetryBuilder
 
ParallelReductionConfig - Class in com.aol.simple.react.stream.lazy
Configuration for incremental parallel reduction batchSize and parallel indicates whether parallel reduction is enabled
ParallelReductionConfig() - Constructor for class com.aol.simple.react.stream.lazy.ParallelReductionConfig
 
parallelStream() - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
partition(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.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 in 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.
partitionFutureStream(Predicate<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Partition an LazyFutureStream into two LazyFutureStreams given a predicate.
peek() - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
peek(Consumer<T>) - Method in class com.aol.simple.react.async.future.ExecutionPipeline
 
peek(Consumer<T>) - Method in class com.aol.simple.react.async.future.PipelineBuilder
 
peek(Consumer<? super U>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
peek(Consumer<? super U>) - Method in interface com.aol.simple.react.stream.traits.EagerSimpleReactStream
Peek asynchronously at the results in the current stage.
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.LazySimpleReactStream
Peek asynchronously at the results in the current stage.
peek(Consumer<? super U>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Peek asynchronously at the results in the current stage.
peekSync(Consumer<? super U>) - Method in interface com.aol.simple.react.stream.traits.EagerSimpleReactStream
Synchronous peek operator
peekSync(Consumer<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
peekSync(Consumer<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
Synchronous peek operator
peekSync(Consumer<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazyToQueue
 
peekSync(Consumer<? super U>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Synchronous peek operator
PipelineBuilder - Class in com.aol.simple.react.async.future
 
PipelineBuilder() - Constructor for class com.aol.simple.react.async.future.PipelineBuilder
 
PipelineBuilder(boolean, Executor) - Constructor for class com.aol.simple.react.async.future.PipelineBuilder
 
Pipes - Class in com.aol.simple.react.async.pipes
Store for Pipes for cross-thread communication
Pipes() - Constructor for class com.aol.simple.react.async.pipes.Pipes
 
PipesToEagerStreams - Class in com.aol.simple.react.async.pipes
 
PipesToEagerStreams() - Constructor for class com.aol.simple.react.async.pipes.PipesToEagerStreams
 
PipesToLazyStreams - Class in com.aol.simple.react.async.pipes
 
PipesToLazyStreams() - Constructor for class com.aol.simple.react.async.pipes.PipesToLazyStreams
 
poll() - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
poll(long, TimeUnit) - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
poll(long, TimeUnit) - Method in class com.aol.simple.react.async.Queue
 
populate(REACTOR) - Method in class com.aol.simple.react.threads.ReactPool
 
populateFromCompletableFuture(CompletableFuture<T>) - Method in class com.aol.simple.react.async.future.FastFuture
 
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
 
publisher(Object, Executor) - Static method in class com.aol.simple.react.async.pipes.Pipes
 
publisher(Object) - Static method in class com.aol.simple.react.async.pipes.Pipes
 
publishTo(Object, Publisher<T>) - Static method in class com.aol.simple.react.async.pipes.Pipes
 
publishToAsync(Object, Publisher<T>) - Static method in class com.aol.simple.react.async.pipes.Pipes
 
pushable(ReactPool<LazyReact>) - Method in class com.aol.simple.react.stream.pushable.MultiplePushableStreamsBuilder
Create a pushable LazyFutureStream using the supplied ReactPool
pushable(ReactPool<LazyReact>) - Method in class com.aol.simple.react.stream.pushable.PushableStreamBuilder
Create a pushable LazyFutureStream using the supplied ReactPool
pushableLazyFutureStream() - Method in class com.aol.simple.react.stream.pushable.MultiplePushableStreamsBuilder
Create a pushable LazyFutureStream.
PushableLazyFutureStream<T> - Class in com.aol.simple.react.stream.pushable
A more concrete Tuple2 impl v1 is Queue<T> v2 is LazyFutureStream<T>
PushableLazyFutureStream(Queue<T>, LazyFutureStream<T>) - Constructor for class com.aol.simple.react.stream.pushable.PushableLazyFutureStream
 
pushableLazyFutureStream() - Method in class com.aol.simple.react.stream.pushable.PushableStreamBuilder
Create a pushable LazyFutureStream.
pushableLazyFutureStream(Adapter<T>) - Method in class com.aol.simple.react.stream.pushable.PushableStreamBuilder
Create a LazyFutureStream.
pushableSeq() - Method in class com.aol.simple.react.stream.pushable.MultiplePushableStreamsBuilder
Create a pushable org.jooq.lambda.Seq
PushableSeq<T> - Class in com.aol.simple.react.stream.pushable
A more concrete Tuple2 impl v1 is Queue<T> v2 is Seq<T>
PushableSeq(Queue<T>, Seq<T>) - Constructor for class com.aol.simple.react.stream.pushable.PushableSeq
 
pushableSeq() - Method in class com.aol.simple.react.stream.pushable.PushableStreamBuilder
Create a pushable org.jooq.lambda.Seq
pushableSeq(Adapter<T>) - Method in class com.aol.simple.react.stream.pushable.PushableStreamBuilder
Create a pushable org.jooq.lambda.Seq
pushableStream() - Method in class com.aol.simple.react.stream.pushable.MultiplePushableStreamsBuilder
Create a pushable JDK 8 Stream
PushableStream<T> - Class in com.aol.simple.react.stream.pushable
A more concrete Tuple2 impl v1 is Queue<T> v2 is Stream<T>
PushableStream(Queue<T>, Stream<T>) - Constructor for class com.aol.simple.react.stream.pushable.PushableStream
 
pushableStream() - Method in class com.aol.simple.react.stream.pushable.PushableStreamBuilder
Create a pushable JDK 8 Stream
pushableStream(Adapter<T>) - Method in class com.aol.simple.react.stream.pushable.PushableStreamBuilder
Create a JDK 8 Stream from the supplied Adapter
PushableStreamBuilder - Class in com.aol.simple.react.stream.pushable
Create Java 8 Streams that data can be pushed into
PushableStreamBuilder() - Constructor for class com.aol.simple.react.stream.pushable.PushableStreamBuilder
 
put(Object) - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 

Q

Queue<T> - Class in com.aol.simple.react.async
Inspired by scalaz-streams async.Queue (functionally similar, but Blocking) A Queue that takes data from one or more input Streams and provides them to one or more output Streams Interface specifies a BlockingQueue, but NonBlockingQueues (such as ConcurrentLinkedQueue can be used in conjunction with an implementation of the Continuation interface
Queue() - Constructor for class com.aol.simple.react.async.Queue
Construct a Queue backed by a LinkedBlockingQueue
Queue(BlockingQueue<T>) - Constructor for class com.aol.simple.react.async.Queue
Queue accepts a BlockingQueue to make use of Blocking semantics
Queue(Queue<T>, WaitStrategy<T>, WaitStrategy<T>) - Constructor for class com.aol.simple.react.async.Queue
 
queue - Variable in class com.aol.simple.react.reactivestreams.FutureStreamSubscriber
 
queue - Variable in class com.aol.simple.react.reactivestreams.JDKReactiveStreamsSubscriber
 
Queue.ClosedQueueException - Exception in com.aol.simple.react.async
Exception thrown if Queue closed
Queue.NIL - Class in com.aol.simple.react.async
 
Queue.QueueReader<T> - Class in com.aol.simple.react.async
 
Queue.QueueTimeoutException - Exception in com.aol.simple.react.async
Exception thrown if Queue polling timesout
queueBackedSignal() - Static method in class com.aol.simple.react.async.Signal
 
QueueFactories - Class in com.aol.simple.react.async.factories
 
QueueFactories() - Constructor for class com.aol.simple.react.async.factories.QueueFactories
 
QueueFactory<T> - Interface in com.aol.simple.react.async.factories
 
QueueReader() - Constructor for class com.aol.simple.react.async.Queue.QueueReader
 
QueueTimeoutException() - Constructor for exception com.aol.simple.react.async.Queue.QueueTimeoutException
 
QueueToBlockingQueueWrapper - Class in com.aol.simple.react.async.factories
 
QueueToBlockingQueueWrapper() - Constructor for class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 

R

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

S

SamplingCollector<T> - Class in com.aol.simple.react.collectors.lazy
Class that allows client code to only collect a sample of results from an Infinite SimpleReact Stream The SamplingCollector won't collect results itself, but hand of control to a consumer that can when Sampling triggered.
SamplingCollector(int, LazyResultConsumer<T>) - Constructor for class com.aol.simple.react.collectors.lazy.SamplingCollector
 
scanLeft(T, BiFunction<T, ? super U, T>) - Method in interface com.aol.simple.react.stream.traits.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 - Static variable in class com.aol.simple.react.config.MaxActive
 
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 class com.aol.simple.react.stream.eager.EagerReact
 
sequentialBuilder() - Static method in class com.aol.simple.react.stream.lazy.LazyReact
 
sequentialBuilder() - Static method in class com.aol.simple.react.stream.simple.SimpleReact
 
sequentialCommonBuilder() - Static method in class com.aol.simple.react.stream.eager.EagerReact
 
sequentialCommonBuilder() - Static method in class com.aol.simple.react.stream.lazy.LazyReact
 
sequentialCommonBuilder() - Static method in class com.aol.simple.react.stream.simple.SimpleReact
 
sequentialCurrentBuilder() - Static method in class com.aol.simple.react.stream.eager.EagerReact
 
sequentialCurrentBuilder() - Static method in class com.aol.simple.react.stream.lazy.LazyReact
 
SequentialElasticPools - Class in com.aol.simple.react.threads
A ReactPool of each type for sequential Streams
SequentialElasticPools() - Constructor for class com.aol.simple.react.threads.SequentialElasticPools
 
set(T) - Method in class com.aol.simple.react.async.future.FastFuture
 
set(T) - Method in class com.aol.simple.react.async.Signal
Set the current value of this signal
setUseCommon(boolean) - Static method in class com.aol.simple.react.stream.ThreadPools
 
shard(Map<K, Queue<U>>, Function<U, K>) - Method in interface com.aol.simple.react.stream.traits.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, RetryExecutor, Boolean) - Constructor for class com.aol.simple.react.stream.simple.SimpleReact
 
SimpleReact(Executor) - Constructor for class com.aol.simple.react.stream.simple.SimpleReact
 
SimpleReact(Executor, RetryExecutor) - Constructor for class com.aol.simple.react.stream.simple.SimpleReact
 
SimpleReact(Executor, RetryExecutor, Executor) - Constructor for class com.aol.simple.react.stream.simple.SimpleReact
 
simpleReact - Static variable in class com.aol.simple.react.threads.ParallelElasticPools
 
simpleReact - Static variable in class com.aol.simple.react.threads.SequentialElasticPools
 
SimpleReactCompletionException - Exception in com.aol.simple.react.exceptions
 
SimpleReactCompletionException(Throwable) - Constructor for exception com.aol.simple.react.exceptions.SimpleReactCompletionException
 
SimpleReactFailedStageException - Exception in com.aol.simple.react.exceptions
 
SimpleReactFailedStageException() - Constructor for exception com.aol.simple.react.exceptions.SimpleReactFailedStageException
 
SimpleReactProcessingException - Exception in com.aol.simple.react.exceptions
 
SimpleReactProcessingException() - Constructor for exception com.aol.simple.react.exceptions.SimpleReactProcessingException
 
SimpleReactProcessingException(String, Throwable, boolean, boolean) - Constructor for exception com.aol.simple.react.exceptions.SimpleReactProcessingException
 
SimpleReactProcessingException(String, Throwable) - Constructor for exception com.aol.simple.react.exceptions.SimpleReactProcessingException
 
SimpleReactProcessingException(String) - Constructor for exception com.aol.simple.react.exceptions.SimpleReactProcessingException
 
SimpleReactProcessingException(Throwable) - Constructor for exception com.aol.simple.react.exceptions.SimpleReactProcessingException
 
SimpleReactStream<U> - Interface in com.aol.simple.react.stream.traits
 
simpleReactStream(CompletableFuture<T>) - Static method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Create a 'free threaded' asynchronous stream that runs on the supplied CompletableFutures executor service (unless async operator invoked , in which it will switch to the common 'free' thread executor) Subsequent tasks will be executed synchronously unless the async() operator is invoked.
simpleReactStream(CompletableFuture<T>...) - Static method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Create a 'free threaded' asynchronous stream that runs on a single thread (not current) The supplier will be executed asyncrhonously, subsequent tasks will be executed synchronously unless the async() operator is invoked.
simpleReactStream(Stream<T>) - Static method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Wrap a Stream into a SimpleReactStream.
simpleReactStream(Iterator<T>) - Static method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Wrap an Iterator into a FutureStream.
SimpleReactStreamComprehender - Class in com.aol.simple.react.monad
Cyclops Monad Comprehender for SimpleReactStreams
SimpleReactStreamComprehender() - Constructor for class com.aol.simple.react.monad.SimpleReactStreamComprehender
 
simpleReactStreamFrom(Stream<CompletableFuture<T>>) - Static method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Create a 'free threaded' asynchronous stream that runs on the supplied CompletableFutures executor service (unless async operator invoked , in which it will switch to the common 'free' thread executor) Subsequent tasks will be executed synchronously unless the async() operator is invoked.
simpleReactStreamFromIterable(Iterable<T>) - Static method in interface com.aol.simple.react.stream.traits.SimpleReactStream
Wrap an Iterable into a FutureStream.
SimpleReactStreamImpl<U> - Class in com.aol.simple.react.stream.simple
 
SimpleReactStreamImpl(SimpleReact, Stream<CompletableFuture<U>>) - Constructor for class com.aol.simple.react.stream.simple.SimpleReactStreamImpl
 
SimpleTimer - Class in com.aol.simple.react.util
Simple Timer class that returns elapsed milliseconds since construction
SimpleTimer() - Constructor for class com.aol.simple.react.util.SimpleTimer
 
single() - Method in class com.aol.simple.react.stream.traits.FutureOps
 
single() - Method in interface com.aol.simple.react.stream.traits.FutureStream
int num = LazyFutureStream.of(1).single(); //num is 1
SingleContinuation - Class in com.aol.simple.react.async
 
SingleContinuation(Queue<?>) - Constructor for class com.aol.simple.react.async.SingleContinuation
 
singleWriterboundedNonBlockingQueue(int) - Static method in class com.aol.simple.react.async.factories.QueueFactories
Creates an async.Queue backed by an Agrona OneToOneConcurrentArrayQueue bounded by specified queueSize Wait strategy used is NoWaitRetry by default for both Consumers and Producers (both Consumers and Producers will repeatedly retry until successful).
size() - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
size() - Method in class com.aol.simple.react.async.Queue
 
skip(long) - Method in interface com.aol.simple.react.stream.traits.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(EagerFutureStream<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(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.
sliding(int) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Create a sliding view over this Stream
sliding(int, int) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
Create a sliding view over this Stream
sliding(int) - Method in interface com.aol.simple.react.stream.traits.FutureStream
Create a sliding view over this Stream
sliding(int, int) - Method in interface com.aol.simple.react.stream.traits.FutureStream
Create a sliding view over this Stream
sliding(int) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Create a sliding view over this Stream
sliding(int, int) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Create a sliding view over this Stream
sliding(Stream<T>, int, int) - Static method in class com.aol.simple.react.stream.traits.operators.SlidingWindow
 
SlidingWindow - Class in com.aol.simple.react.stream.traits.operators
 
SlidingWindow() - Constructor for class com.aol.simple.react.stream.traits.operators.SlidingWindow
 
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
 
SpinWait<T> - Class in com.aol.simple.react.async.wait
Repeatedly retry to take or offer element to Queue if full or data unavailable, with a wait of 1 nano second between retries
SpinWait() - Constructor for class com.aol.simple.react.async.wait.SpinWait
 
splitAt(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 class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
spliterator() - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
StageWithResults<RS,U> - Class in com.aol.simple.react.stream
 
StageWithResults(ConfigurableStream<U, Object>, 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.factories.QueueToBlockingQueueWrapper
 
stream(Adapter<V>) - Static method in class com.aol.simple.react.async.pipes.PipesToEagerStreams
 
stream(Object) - Static method in class com.aol.simple.react.async.pipes.PipesToLazyStreams
 
stream() - Method in class com.aol.simple.react.async.Queue
 
stream(Continueable) - Method in class com.aol.simple.react.async.Queue
 
stream() - Method in class com.aol.simple.react.async.Topic
Generating a stream will register the Stream as a subscriber to this topic.
stream - Variable in class com.aol.simple.react.reactivestreams.FutureStreamSubscriber
 
stream() - Method in class com.aol.simple.react.reactivestreams.FutureStreamSubscriber
 
stream - Variable in class com.aol.simple.react.reactivestreams.JDKReactiveStreamsSubscriber
 
stream() - Method in class com.aol.simple.react.reactivestreams.JDKReactiveStreamsSubscriber
 
stream(Function<Stream<CompletableFuture>, Stream<CompletableFuture>>) - Method in class com.aol.simple.react.stream.EagerStreamWrapper
 
stream() - Method in class com.aol.simple.react.stream.EagerStreamWrapper
 
stream() - Method in class com.aol.simple.react.stream.LazyStreamWrapper
 
stream() - Method in interface com.aol.simple.react.stream.StreamWrapper
 
stream() - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
stream() - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
stream() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
stream(Iterator<U>) - Static method in class com.aol.simple.react.stream.traits.operators.SlidingWindow
 
stream() - Method in class com.aol.simple.react.stream.traits.RepeatableStream
 
streamBatch(Continueable, Function<BiFunction<Long, TimeUnit, T>, Supplier<Collection<T>>>) - Method in class com.aol.simple.react.async.Queue
 
streamBatchNoTimeout(Continueable, Function<Supplier<T>, Supplier<Collection<T>>>) - Method in class com.aol.simple.react.async.Queue
 
streamCompletableFutures() - Method in interface com.aol.simple.react.async.Adapter
 
streamCompletableFutures() - Method in class com.aol.simple.react.async.Queue
 
streamCompletableFutures() - Method in class com.aol.simple.react.async.Topic
Generating a streamCompletableFutures will register the Stream as a subscriber to this topic.
streamCompletableFutures() - Method in interface com.aol.simple.react.stream.traits.EagerSimpleReactStream
 
streamCompletableFutures() - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
 
streamCompletableFutures() - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
streamControl(Continueable, Function<Supplier<T>, Supplier<T>>) - Method in class com.aol.simple.react.async.Queue
 
streamControlFutures(Continueable, Function<Supplier<T>, CompletableFuture<T>>) - Method in class com.aol.simple.react.async.Queue
 
StreamCopier - Class in com.aol.simple.react.stream.traits.operators
 
StreamCopier() - Constructor for class com.aol.simple.react.stream.traits.operators.StreamCopier
 
streamCPUBound(Adapter<V>) - Static method in class com.aol.simple.react.async.pipes.PipesToEagerStreams
Pass in a Queue, and get back a listening EagerFutureStream optimized for CPU Bound operations Convert the EagerFutureStream to async mode to fan out operations across threads, after the first fan out operation definition it should be converted to sync mode
streamCPUBound(Object) - Static method in class com.aol.simple.react.async.pipes.PipesToLazyStreams
 
streamIOBound(Adapter<V>) - Static method in class com.aol.simple.react.async.pipes.PipesToEagerStreams
Pass in a Queue, and get back a listening EagerFutureStream optimized for IO Bound operations
streamIOBound(Object) - Static method in class com.aol.simple.react.async.pipes.PipesToLazyStreams
 
StreamOfContinuations - Class in com.aol.simple.react.async
 
StreamOfContinuations(Queue<?>) - Constructor for class com.aol.simple.react.async.StreamOfContinuations
 
StreamWrapper<U> - Interface in com.aol.simple.react.stream
 
submit(Function<RS, R>) - Method in class com.aol.simple.react.stream.StageWithResults
This method allows the SimpleReact Executor to be reused by JDK parallel streams.
submit(Callable<T>) - Method in class com.aol.simple.react.stream.StageWithResults
This method allows the SimpleReact Executor to be reused by JDK parallel streams
subscribe(Subscriber<? super T>) - Method in interface com.aol.simple.react.reactivestreams.FutureStreamAsyncPublisher
 
subscribe(Subscriber<? super T>) - Method in interface com.aol.simple.react.reactivestreams.FutureStreamSynchronousPublisher
 
subscribe(Subscriber<? super T>) - Method in class com.aol.simple.react.reactivestreams.JDKReactiveStreamsPublisher
 
subscribe(Subscriber<? super U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
subscribeAsync(Subscriber<? super T>) - Method in interface com.aol.simple.react.reactivestreams.FutureStreamAsyncPublisher
 
subscribeOn(Subscriber<? super T>, Executor) - Method in interface com.aol.simple.react.reactivestreams.FutureStreamAsyncPublisher
 
subscribeSync(Subscriber<? super T>) - Method in interface com.aol.simple.react.reactivestreams.FutureStreamSynchronousPublisher
 
subscribeTo(Object, Subscriber<T>, Executor) - Static method in class com.aol.simple.react.async.pipes.Pipes
 
Subscription - Class in com.aol.simple.react.async.subscription
 
Subscription() - Constructor for class com.aol.simple.react.async.subscription.Subscription
 
sumDouble(ToDoubleFunction<T>) - Method in interface com.aol.simple.react.stream.traits.future.operators.DoubleOperators
Perform an asynchronous sum operation
sumInt(ToIntFunction<T>) - Method in interface com.aol.simple.react.stream.traits.future.operators.IntOperators
Perform an asynchronous sum operation
sumLong(ToLongFunction<T>) - Method in interface com.aol.simple.react.stream.traits.future.operators.LongOperators
Perform an asynchronous sum operation
summaryStatisticsDouble(ToDoubleFunction<T>) - Method in interface com.aol.simple.react.stream.traits.future.operators.DoubleOperators
Perform an asynchronous summaryStatistics operation
summaryStatisticsInt(ToIntFunction<T>) - Method in interface com.aol.simple.react.stream.traits.future.operators.IntOperators
Perform an asynchronous summaryStatistics operation
summaryStatisticsLong(ToLongFunction<T>) - Method in interface com.aol.simple.react.stream.traits.future.operators.LongOperators
Perform an asynchronous summaryStatistics operation
switchOnNextValue(Stream<LazyFutureStream>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Merges this stream and the supplied Streams into a single Stream where the next value is the next returned across any of the involved Streams.
switchToCPU(EagerFutureStream<T>) - Method in interface com.aol.simple.react.mixins.EagerReactive
Switch EagerFutureStream into execution mode suitable for CPU bound execution (reuse cpuReactors task executor)
switchToCPU(LazyFutureStream<T>) - Method in interface com.aol.simple.react.mixins.LazyReactive
Switch LazyFutureStream into execution mode suitable for CPU bound execution (reuse cpuReactors task executor)
switchToIO(EagerFutureStream<T>) - Method in interface com.aol.simple.react.mixins.EagerReactive
Switch EagerFutureStream into execution mode suitable for IO (reuse ioReactors task executor)
switchToIO(LazyFutureStream<T>) - Method in interface com.aol.simple.react.mixins.LazyReactive
Switch LazyFutureStream into execution mode suitable for IO (reuse ioReactors task executor)
sync(Function<EagerReact, EagerFutureStream<T>>) - Method in interface com.aol.simple.react.mixins.EagerReactive
Generate a sequentially executing single-threaded a EagerFutureStream that executes all tasks directly without involving a task executor between each stage (unless async operator invoked).
sync(Function<LazyReact, LazyFutureStream<T>>) - Method in interface com.aol.simple.react.mixins.LazyReactive
Generate a sequentially executing single-threaded a LazyFutureStream that executes all tasks directly without involving a task executor between each stage (unless async operator invoked).
sync() - Method in class com.aol.simple.react.stream.lazy.LazyReact
Start any created Streams in syncrhonous mode - that is tasks will be executed on the calling thread
sync() - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
sync() - Method in interface com.aol.simple.react.stream.traits.EagerSimpleReactStream
 
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.factories.QueueFactories
 
syncrhonousPool() - Static method in class com.aol.simple.react.threads.ReactPool
 

T

take() - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
take(WaitStrategy.Takeable<T>) - Method in class com.aol.simple.react.async.wait.DirectWaitStrategy
 
take(WaitStrategy.Takeable<T>) - Method in class com.aol.simple.react.async.wait.ExponentialBackofWaitStrategy
 
take(WaitStrategy.Takeable<T>) - Method in class com.aol.simple.react.async.wait.NoWaitRetry
 
take(WaitStrategy.Takeable<T>) - Method in class com.aol.simple.react.async.wait.SpinWait
 
take(WaitStrategy.Takeable<T>) - Method in interface com.aol.simple.react.async.wait.WaitStrategy
 
take() - Method in interface com.aol.simple.react.async.wait.WaitStrategy.Takeable
 
take(WaitStrategy.Takeable<T>) - Method in class com.aol.simple.react.async.wait.YieldWait
 
takeUntil(EagerFutureStream<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.
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>, Executor) - Method in interface com.aol.simple.react.stream.traits.EagerSimpleReactStream
 
then(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.EagerSimpleReactStream
React then Unlike 'with' this method is fluent, and returns another Stage Builder that can represent the next stage in the dataflow.
then(Function<U, R>, Executor) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
then(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
Override return type on SimpleReactStream
then(Function<U, R>, Executor) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
 
then(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
React then Unlike 'with' this method is fluent, and returns another Stage Builder that can represent the next stage in the dataflow.
then(Function<U, R>, Executor) - Method in interface com.aol.simple.react.stream.traits.LazyToQueue
 
then(Function<U, R>, Executor) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
then(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
React then Unlike 'with' this method is fluent, and returns another Stage Builder that can represent the next stage in the dataflow.
thenApply(Function<T, R>) - Method in class com.aol.simple.react.async.future.ExecutionPipeline
 
thenApply(Function<T, R>) - Method in class com.aol.simple.react.async.future.PipelineBuilder
 
thenApplyAsync(Function<T, R>, Executor) - Method in class com.aol.simple.react.async.future.ExecutionPipeline
 
thenApplyAsync(Function<T, R>, Executor) - Method in class com.aol.simple.react.async.future.PipelineBuilder
 
thenCompose(Function<T, CompletableFuture<R>>) - Method in class com.aol.simple.react.async.future.ExecutionPipeline
 
thenCompose(Function<T, CompletableFuture<R>>) - Method in class com.aol.simple.react.async.future.PipelineBuilder
 
thenComposeAsync(Function<Object, CompletableFuture<?>>, Executor) - Method in class com.aol.simple.react.async.future.ExecutionPipeline
 
thenComposeAsync(Function<T, CompletableFuture<R>>, Executor) - Method in class com.aol.simple.react.async.future.PipelineBuilder
 
thenSync(Function<U, R>) - Method in class com.aol.simple.react.stream.simple.SimpleReactStreamImpl
 
thenSync(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
thenSync(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.EagerSimpleReactStream
 
thenSync(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.EagerToQueue
 
thenSync(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
thenSync(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
 
thenSync(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.LazyToQueue
 
thenSync(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
ThreadPools - Class in com.aol.simple.react.stream
 
ThreadPools() - Constructor for class com.aol.simple.react.stream.ThreadPools
 
ThreadPools.ExecutionMode - Enum in com.aol.simple.react.stream
 
throwSoftenedException(Throwable) - Method in class com.aol.simple.react.exceptions.ExceptionSoftener
 
ThrowsSoftened - Annotation Type in com.aol.simple.react.exceptions
 
toArray() - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
toArray(Object[]) - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
toArray(IntFunction<A[]>) - Method in class com.aol.simple.react.stream.traits.FutureOps
Asyncrhonously generate an Array
toArray() - Method in class com.aol.simple.react.stream.traits.FutureOps
Asyncrhonously generate an Array
toArray() - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
toArray(IntFunction<A[]>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
toBufferingCopier(Iterator<A>, int) - Static method in class com.aol.simple.react.stream.traits.operators.StreamCopier
 
toBufferingDuplicator(Iterator<A>) - Static method in class com.aol.simple.react.stream.traits.operators.StreamCopier
 
toBufferingDuplicator(Iterator<A>, long) - Static method in class com.aol.simple.react.stream.traits.operators.StreamCopier
 
toCollection(Supplier<C>) - Method in class com.aol.simple.react.stream.traits.FutureOps
Asynchronously perform a Stream collection
toCompletableFuture() - Method in class com.aol.simple.react.async.future.FastFuture
 
toConcurrentLazyCollection(Stream<A>) - Static method in class com.aol.simple.react.stream.traits.future.operators.ToLazyCollection
Lazily constructs a Collection from specified Stream.
toConcurrentLazyCollection(Iterator<A>) - Static method in class com.aol.simple.react.stream.traits.future.operators.ToLazyCollection
 
toConcurrentLazyCollection() - Method in interface com.aol.simple.react.stream.traits.FutureStream
Create a LazyCollection access to which is synchronized
toFinalPipeline() - Method in class com.aol.simple.react.async.future.ExecutionPipeline
 
ToLazyCollection - Class in com.aol.simple.react.stream.traits.future.operators
 
ToLazyCollection() - Constructor for class com.aol.simple.react.stream.traits.future.operators.ToLazyCollection
 
toLazyCollection(Stream<A>) - Static method in class com.aol.simple.react.stream.traits.future.operators.ToLazyCollection
Projects an immutable collection of this stream.
toLazyCollection(Iterator<A>) - Static method in class com.aol.simple.react.stream.traits.future.operators.ToLazyCollection
 
toLazyCollection() - Method in interface com.aol.simple.react.stream.traits.FutureStream
Collection<Integer> col = LazyFutureStream.of(1,2,3,4,5,6) .map(i->i+2) .toLazyCollection();
toList() - Method in class com.aol.simple.react.stream.traits.FutureOps
Asynchronously convert this Stream into a List
Topic<T> - Class in com.aol.simple.react.async
A class that can accept input streams and generate output streams where data sent in the Topic is guaranteed to be provided to all Topic subsribers
Topic() - Constructor for class com.aol.simple.react.async.Topic
Construct a new Topic
Topic(Queue<T>) - Constructor for class com.aol.simple.react.async.Topic
Construct a Topic using the Queue provided
topicBackedSignal() - Static method in class com.aol.simple.react.async.Signal
 
toQueue() - Method in interface com.aol.simple.react.reactivestreams.FutureStreamAsyncPublisher
 
toQueue() - Method in interface com.aol.simple.react.reactivestreams.FutureStreamSynchronousPublisher
 
toQueue() - Method in class com.aol.simple.react.stream.simple.SimpleReactStreamImpl
 
toQueue() - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
toQueue() - Method in interface com.aol.simple.react.stream.traits.EagerToQueue
Convert the current Stream to a SimpleReact Queue
toQueue(Function<Queue, Queue>) - Method in interface com.aol.simple.react.stream.traits.EagerToQueue
 
toQueue(Map<K, Queue<U>>, Function<U, K>) - Method in interface com.aol.simple.react.stream.traits.EagerToQueue
 
toQueue() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
toQueue() - Method in interface com.aol.simple.react.stream.traits.LazyToQueue
Convert the current Stream to a simple-react Queue
toQueue(Function<Queue, Queue>) - Method in interface com.aol.simple.react.stream.traits.LazyToQueue
 
toQueue(Map<K, Queue<U>>, Function<U, K>) - Method in interface com.aol.simple.react.stream.traits.LazyToQueue
 
toQueue() - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
ToQueue<U> - Interface in com.aol.simple.react.stream.traits
interface that defines the conversion of an object to a queue
toQueue() - Method in interface com.aol.simple.react.stream.traits.ToQueue
 
toQueue(Map<K, Queue<U>>, Function<U, K>) - Method in interface com.aol.simple.react.stream.traits.ToQueue
Sharded data in queues
toQueue(Function<Queue, Queue>) - Method in interface com.aol.simple.react.stream.traits.ToQueue
Method to create a Queue that can be modified by supplied funciton
toSet() - Method in class com.aol.simple.react.stream.traits.FutureOps
Asynchronously convert this Stream into a List
toString() - Method in class com.aol.simple.react.async.factories.QueueToBlockingQueueWrapper
 
tryAdvance(Consumer<? super T>) - Method in class com.aol.simple.react.async.ClosingSpliterator
 
tryAdvance(Consumer<? super T>) - Method in class com.aol.simple.react.stream.InfiniteClosingSpliterator
 
tryAdvance(Consumer<? super T>) - Method in class com.aol.simple.react.stream.InfiniteClosingSpliteratorFromIterator
 
trySplit() - Method in class com.aol.simple.react.async.ClosingSpliterator
 
trySplit() - Method in class com.aol.simple.react.stream.InfiniteClosingSpliterator
 
trySplit() - Method in class com.aol.simple.react.stream.InfiniteClosingSpliteratorFromIterator
 

U

unboundedNonBlockingQueue() - Static method in class com.aol.simple.react.async.factories.QueueFactories
Creates an async.Queue backed by a JDK Wait Free unbounded ConcurrentLinkedQueue Wait strategy used is NoWaitRetry by default for both Consumers and Producers (both Consumers and Producers will repeatedly retry until successful).
unboundedPool(Collection<REACTOR>) - Static method in class com.aol.simple.react.threads.ReactPool
If all REACTORs are in use calling react will block.
unboundedQueue() - Static method in class com.aol.simple.react.async.factories.QueueFactories
 
unboundedWaitFree() - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
This is the default setting, internal queues are backed by a ConcurrentLinkedQueue This operator will return the next stage to using this Queue type if it has been changed
unordered() - Method in interface com.aol.simple.react.stream.traits.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<T> - Class in com.aol.simple.react.stream.traits
 
Val() - Constructor for class com.aol.simple.react.stream.traits.Val
 
valueOf(String) - Static method in enum com.aol.simple.react.exceptions.ExceptionSoftener.singleton
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.aol.simple.react.RetryBuilder.factory
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.aol.simple.react.stream.ThreadPools.ExecutionMode
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.aol.simple.react.exceptions.ExceptionSoftener.singleton
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.aol.simple.react.RetryBuilder.factory
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.aol.simple.react.stream.ThreadPools.ExecutionMode
Returns an array containing the constants of this enum type, in the order they are declared.

W

WaitStrategy<T> - Interface in com.aol.simple.react.async.wait
 
WaitStrategy.Offerable - Interface in com.aol.simple.react.async.wait
 
WaitStrategy.Takeable<T> - Interface in com.aol.simple.react.async.wait
 
whenComplete(BiConsumer<T, X>) - Method in class com.aol.simple.react.async.future.ExecutionPipeline
 
whenComplete(BiConsumer<T, X>) - Method in class com.aol.simple.react.async.future.PipelineBuilder
 
with(Function<U, R>) - Method in interface com.aol.simple.react.stream.traits.EagerSimpleReactStream
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
 
withAsync(boolean) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
withAsync(boolean) - Method in interface com.aol.simple.react.stream.traits.EagerSimpleReactStream
 
withAsync(boolean) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
withAsync(boolean) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
 
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.EagerSimpleReactStream
 
withErrorHandler(Optional<Consumer<Throwable>>) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
 
withLastActive(LazyStreamWrapper) - Method in class com.aol.simple.react.stream.lazy.LazyFutureStreamImpl
 
withLastActive(EagerStreamWrapper) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
withLastActive(EagerStreamWrapper) - Method in interface com.aol.simple.react.stream.traits.EagerSimpleReactStream
 
withLastActive(LazyStreamWrapper<R>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
withLastActive(LazyStreamWrapper<R>) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
 
withLatest(EagerFutureStream<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.
withLazyCollector(Supplier<LazyResultConsumer<U>>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
withNewStream(Stream<CompletableFuture>, BaseSimpleReact) - Method in class com.aol.simple.react.stream.EagerStreamWrapper
 
withNewStream(Stream<R>) - Method in class com.aol.simple.react.stream.LazyStreamWrapper
 
withNewStream(Stream<R>, LazyReact) - Method in class com.aol.simple.react.stream.LazyStreamWrapper
 
withParallelReduction(ParallelReductionConfig) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
withPublisherExecutor(Executor) - Method in interface com.aol.simple.react.reactivestreams.FutureStreamAsyncPublisher
 
withQueueCopyExecutor(Executor) - Method in class com.aol.simple.react.stream.eager.EagerReact
 
withQueueCopyExecutor(Executor) - Method in class com.aol.simple.react.stream.simple.SimpleReact
 
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.EagerSimpleReactStream
 
withQueueFactory(QueueFactory<U>) - Method in interface com.aol.simple.react.stream.traits.FutureStream
 
withQueueFactory(QueueFactory<U>) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
withQueueFactory(QueueFactory<U>) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
 
withQueueFactory(QueueFactory<U>) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
withResults(Collection<FastFuture<T>>) - Method in class com.aol.simple.react.collectors.lazy.EmptyCollector
 
withResults(Collection<FastFuture<T>>) - Method in interface com.aol.simple.react.collectors.lazy.LazyResultConsumer
Used to generate a new instance for result collection - populates the supplied Collection
withResults(Collection<FastFuture<T>>) - Method in class com.aol.simple.react.collectors.lazy.SamplingCollector
 
withRetrier(RetryExecutor) - Method in class com.aol.simple.react.stream.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
 
withRetrier(RetryExecutor) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
withRetrier(RetryExecutor) - Method in interface com.aol.simple.react.stream.traits.EagerSimpleReactStream
 
withRetrier(RetryExecutor) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
withRetrier(RetryExecutor) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
 
withRetrier(RetryExecutor) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
withStream(Stream) - Method in class com.aol.simple.react.stream.LazyStreamWrapper
 
withSubscription(Continueable) - Method in interface com.aol.simple.react.stream.traits.ConfigurableStream
 
withSubscription(Continueable) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
withSubscription(Continueable) - Method in interface com.aol.simple.react.stream.traits.EagerSimpleReactStream
 
withSubscription(Continueable) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
withSubscription(Continueable) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
 
withSubscription(Continueable) - Method in interface com.aol.simple.react.stream.traits.SimpleReactStream
 
withTaskExecutor(Executor) - Method in class com.aol.simple.react.stream.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
 
withTaskExecutor(Executor) - Method in interface com.aol.simple.react.stream.traits.EagerFutureStream
 
withTaskExecutor(Executor) - Method in interface com.aol.simple.react.stream.traits.EagerSimpleReactStream
 
withTaskExecutor(Executor) - Method in interface com.aol.simple.react.stream.traits.LazyFutureStream
 
withTaskExecutor(Executor) - Method in interface com.aol.simple.react.stream.traits.LazySimpleReactStream
 

X

xOf(int, Runnable, FastFuture...) - Static method in class com.aol.simple.react.async.future.FastFuture
 
xPer(int, long, TimeUnit) - Method in interface com.aol.simple.react.stream.traits.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

Y

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

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 Y Z 
Skip navigation links