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

A

a() - Method in class com.github.davidmoten.rx2.util.Pair
 
accept(A, B, C) - Method in interface com.github.davidmoten.rx2.functions.Consumer3
 
accept(State, StateMachine.Emitter<Out>) - Method in interface com.github.davidmoten.rx2.StateMachine.Completion2
 
accept(State, Throwable, StateMachine.Emitter<Out>) - Method in interface com.github.davidmoten.rx2.StateMachine.Errored
 
acceptSocketIf(Predicate<? super Socket>) - Method in class com.github.davidmoten.rx2.IO.ServerSocketBuilder
 
acceptTimeoutMs(int) - Method in class com.github.davidmoten.rx2.IO.ServerSocketBuilder
 
action(Consumer<? super RetryWhen.ErrorAndDuration>) - Static method in class com.github.davidmoten.rx2.RetryWhen
 
action(Consumer<? super RetryWhen.ErrorAndDuration>) - Method in class com.github.davidmoten.rx2.RetryWhen.Builder
 
Actions - Class in com.github.davidmoten.rx2
 
add(String) - Method in class com.github.davidmoten.rx2.internal.flowable.DelimitedStringLinkedList
 
add(Number) - Method in class com.github.davidmoten.rx2.Statistics
 
add(T) - Method in class com.github.davidmoten.util.RingBuffer
 
addAll(Collection<? extends T>) - Method in class com.github.davidmoten.util.RingBuffer
 
addCalled() - Method in class com.github.davidmoten.rx2.internal.flowable.DelimitedStringLinkedList
 
addLongTo(List<Long>) - Static method in class com.github.davidmoten.rx2.Consumers
 
addTo(List<T>) - Static method in class com.github.davidmoten.rx2.Consumers
 
alwaysFalse() - Static method in class com.github.davidmoten.rx2.BiPredicates
 
alwaysFalse() - Static method in class com.github.davidmoten.rx2.Predicates
 
alwaysTrue() - Static method in class com.github.davidmoten.rx2.BiPredicates
 
alwaysTrue() - Static method in class com.github.davidmoten.rx2.Predicates
 
apply(Flowable<In>) - Method in class com.github.davidmoten.rx2.internal.flowable.TransformerStateMachine
 
apply(State, In, FlowableEmitter<Out>) - Method in interface com.github.davidmoten.rx2.StateMachine.Transition
 
apply(State, In, StateMachine.Emitter<Out>) - Method in interface com.github.davidmoten.rx2.StateMachine.Transition2
 
assertBytesEquals(byte[]) - Static method in class com.github.davidmoten.rx2.Consumers
 
AssertionException - Exception in com.github.davidmoten.rx2.exceptions
 
AssertionException(String) - Constructor for exception com.github.davidmoten.rx2.exceptions.AssertionException
 
avail(int) - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.Page
 
avail() - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.Pages
 

B

b() - Method in class com.github.davidmoten.rx2.util.Pair
 
backpressureStrategy(BackpressureStrategy) - Method in class com.github.davidmoten.rx2.StateMachine.Builder3
 
backpressureStrategy(BackpressureStrategy) - Method in class com.github.davidmoten.rx2.StateMachine2.Builder3
 
batchSize(int) - Method in class com.github.davidmoten.rx2.Flowables.MergeInterleaveBuilder
 
BiFunctions - Class in com.github.davidmoten.rx2
 
BiPredicates - Class in com.github.davidmoten.rx2
 
blockUntilWorkFinished(Scheduler, int, long, TimeUnit) - Static method in class com.github.davidmoten.rx2.SchedulerHelper
 
blockUntilWorkFinished(Scheduler, int) - Static method in class com.github.davidmoten.rx2.SchedulerHelper
 
buffer(int, long, TimeUnit) - Static method in class com.github.davidmoten.rx2.flowable.Transformers
Buffers the source Flowable into Lists, emitting Lists when the size of a list reaches maxSize or if the elapsed time since last emission from the source reaches the given duration.
buffer(int, long, TimeUnit, Scheduler) - Static method in class com.github.davidmoten.rx2.flowable.Transformers
Buffers the source Flowable into Lists, emitting Lists when the size of a list reaches maxSize or if the elapsed time since last emission from the source reaches the given duration.
buffer(int, Function<? super T, ? extends Long>, TimeUnit) - Static method in class com.github.davidmoten.rx2.flowable.Transformers
Buffers the source Flowable into Lists, emitting Lists when the size of a list reaches maxSize or if the elapsed time since last emission from the source reaches the given duration.
buffer(int, Function<? super T, ? extends Long>, TimeUnit, Scheduler) - Static method in class com.github.davidmoten.rx2.flowable.Transformers
Buffers the source Flowable into Lists, emitting Lists when the size of a list reaches maxSize or if the elapsed time since last emission from the source reaches the given duration.
bufferSize(int) - Method in class com.github.davidmoten.rx2.IO.ServerSocketBuilder
 
BufferToFileSubscriberFlowable(Subscriber<? super T>, PagedQueue, Serializer<T>, Scheduler.Worker) - Constructor for class com.github.davidmoten.rx2.internal.flowable.buffertofile.FlowableOnBackpressureBufferToFile.BufferToFileSubscriberFlowable
 
bufferWhile(BiPredicate<? super List<T>, ? super T>, boolean) - Static method in class com.github.davidmoten.rx2.flowable.Transformers
 
bufferWhile(BiPredicate<? super List<T>, ? super T>) - Static method in class com.github.davidmoten.rx2.flowable.Transformers
 
build() - Method in class com.github.davidmoten.rx2.Flowables.MergeInterleaveBuilder
 
build() - Method in class com.github.davidmoten.rx2.RetryWhen.Builder
 
build() - Method in class com.github.davidmoten.rx2.StateMachine.Builder3
 
build() - Method in class com.github.davidmoten.rx2.StateMachine2.Builder3
 
builder() - Static method in class com.github.davidmoten.rx2.StateMachine
 
builder() - Static method in class com.github.davidmoten.rx2.StateMachine2
 
builderFlowable() - Static method in class com.github.davidmoten.rx2.buffertofile.Options
 
builderObservable() - Static method in class com.github.davidmoten.rx2.buffertofile.Options
 
Burst<T> - Class in com.github.davidmoten.rx2.flowable
Creates Flowable of a number of items followed by either an error or completion.
Burst.Builder<T> - Class in com.github.davidmoten.rx2.flowable
 
bytes() - Static method in class com.github.davidmoten.rx2.buffertofile.Serializers
 
Bytes - Class in com.github.davidmoten.rx2
 

C

cache(Flowable<T>) - Static method in class com.github.davidmoten.rx2.Flowables
Returns a cached Flowable like Flowable.cache() except that the cache can be reset by calling CachedFlowable.reset().
cache(Flowable<T>, long, TimeUnit, Scheduler.Worker) - Static method in class com.github.davidmoten.rx2.Flowables
Returns a cached Flowable like Flowable.cache() except that the cache can be reset by calling CachedFlowable.reset() and the cache will be automatically reset an interval after first subscription (or first subscription after reset).
cache(Flowable<T>, long, TimeUnit, Scheduler) - Static method in class com.github.davidmoten.rx2.Flowables
Returns a cached Flowable like Flowable.cache() except that the cache may be reset by the user calling CloseableFlowableWithReset.reset().
cache(Observable<T>) - Static method in class com.github.davidmoten.rx2.Observables
Returns a cached Flowable like Flowable.cache() except that the cache can be reset by calling CachedFlowable.reset().
cache(Observable<T>, long, TimeUnit, Scheduler.Worker) - Static method in class com.github.davidmoten.rx2.Observables
Returns a cached Observable like Observable.cache() except that the cache can be reset by calling reset() and the cache will be automatically reset an interval after first subscription (or first subscription after reset).
cache(Observable<T>, long, TimeUnit, Scheduler) - Static method in class com.github.davidmoten.rx2.Observables
Returns a cached Observable like Observable.cache() except that the cache may be reset by the user calling CloseableObservableWithReset.reset().
CachedFlowable<T> - Class in com.github.davidmoten.rx2.flowable
 
CachedFlowable(Flowable<T>) - Constructor for class com.github.davidmoten.rx2.flowable.CachedFlowable
 
CachedObservable<T> - Class in com.github.davidmoten.rx2.observable
 
CachedObservable(Observable<T>) - Constructor for class com.github.davidmoten.rx2.observable.CachedObservable
 
Callables - Class in com.github.davidmoten.rx2
 
cancel() - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.FlowableOnBackpressureBufferToFile.BufferToFileSubscriberFlowable
 
cancel_() - Method in interface com.github.davidmoten.rx2.StateMachine.Emitter
 
cancelUpstream() - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.FlowableOnBackpressureBufferToFile.BufferToFileSubscriberFlowable
 
clear() - Method in class com.github.davidmoten.rx2.internal.flowable.DelimitedStringLinkedList
 
clear() - Method in class com.github.davidmoten.util.RingBuffer
 
close() - Static method in class com.github.davidmoten.rx2.Consumers
 
close() - Method in class com.github.davidmoten.rx2.flowable.CloseableFlowableWithReset
 
close(PagedQueue) - Static method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.FlowableOnBackpressureBufferToFile
 
close() - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.MemoryMappedFile
 
close() - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.Page
 
close() - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.PagedQueue
 
close() - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.Pages
 
close() - Method in class com.github.davidmoten.rx2.observable.CloseableObservableWithReset
 
CloseableFlowableWithReset<T> - Class in com.github.davidmoten.rx2.flowable
 
CloseableFlowableWithReset(Flowable<T>, Runnable, Runnable) - Constructor for class com.github.davidmoten.rx2.flowable.CloseableFlowableWithReset
 
CloseableObservableWithReset<T> - Class in com.github.davidmoten.rx2.observable
 
CloseableObservableWithReset(Observable<T>, Runnable, Runnable) - Constructor for class com.github.davidmoten.rx2.observable.CloseableObservableWithReset
 
collect(Flowable<byte[]>) - Static method in class com.github.davidmoten.rx2.Bytes
 
collect() - Static method in class com.github.davidmoten.rx2.Bytes
 
collectStats() - Static method in class com.github.davidmoten.rx2.BiFunctions
 
collectStats() - Static method in class com.github.davidmoten.rx2.flowable.Transformers
Converts a stream of Number to a stream of Statistics about those numbers.
collectStats(Function<? super T, ? extends R>) - Static method in class com.github.davidmoten.rx2.flowable.Transformers
 
collectWhile(Callable<R>, BiFunction<? super R, ? super T, ? extends R>, BiPredicate<? super R, ? super T>, boolean) - Static method in class com.github.davidmoten.rx2.flowable.Transformers
Returns a transformer that emits collections of items with the collection boundaries determined by the given BiPredicate.
collectWhile(Callable<R>, BiFunction<? super R, ? super T, ? extends R>, BiPredicate<? super R, ? super T>) - Static method in class com.github.davidmoten.rx2.flowable.Transformers
 
com.github.davidmoten.rx2 - package com.github.davidmoten.rx2
 
com.github.davidmoten.rx2.buffertofile - package com.github.davidmoten.rx2.buffertofile
 
com.github.davidmoten.rx2.exceptions - package com.github.davidmoten.rx2.exceptions
 
com.github.davidmoten.rx2.flowable - package com.github.davidmoten.rx2.flowable
 
com.github.davidmoten.rx2.functions - package com.github.davidmoten.rx2.functions
 
com.github.davidmoten.rx2.internal - package com.github.davidmoten.rx2.internal
 
com.github.davidmoten.rx2.internal.flowable - package com.github.davidmoten.rx2.internal.flowable
 
com.github.davidmoten.rx2.internal.flowable.buffertofile - package com.github.davidmoten.rx2.internal.flowable.buffertofile
 
com.github.davidmoten.rx2.internal.observable - package com.github.davidmoten.rx2.internal.observable
 
com.github.davidmoten.rx2.observable - package com.github.davidmoten.rx2.observable
 
com.github.davidmoten.rx2.util - package com.github.davidmoten.rx2.util
 
com.github.davidmoten.util - package com.github.davidmoten.util
 
completion(StateMachine.Completion<State, Out>) - Method in class com.github.davidmoten.rx2.StateMachine.Builder3
 
completion(StateMachine.Completion2<State, Out>) - Method in class com.github.davidmoten.rx2.StateMachine2.Builder3
 
concat(Flowable<String>) - Static method in class com.github.davidmoten.rx2.Strings
 
concat(Flowable<String>, String) - Static method in class com.github.davidmoten.rx2.Strings
 
concat(String) - Static method in class com.github.davidmoten.rx2.Strings
 
concat() - Static method in class com.github.davidmoten.rx2.Strings
 
constant(S) - Static method in class com.github.davidmoten.rx2.BiFunctions
 
constant(T) - Static method in class com.github.davidmoten.rx2.Callables
 
constant(T) - Static method in class com.github.davidmoten.rx2.Functions
 
Consumer3<A,B,C> - Interface in com.github.davidmoten.rx2.functions
 
Consumers - Class in com.github.davidmoten.rx2
 
contains(Object) - Method in class com.github.davidmoten.util.RingBuffer
 
containsAll(Collection<?>) - Method in class com.github.davidmoten.util.RingBuffer
 
count() - Method in class com.github.davidmoten.rx2.Statistics
 
create() - Method in class com.github.davidmoten.rx2.flowable.Burst.Builder
 
create(BiFunction<? super Long, ? super Long, ? extends Flowable<T>>, long, int) - Static method in class com.github.davidmoten.rx2.internal.flowable.FlowableFetchPagesByRequest
 
create(Callable<? extends ServerSocket>, int, int, Action, int, Predicate<? super Socket>) - Static method in class com.github.davidmoten.rx2.internal.flowable.FlowableServerSocket
 
create(Callable<? extends State>, Function3<? super State, ? super In, ? super FlowableEmitter<Out>, ? extends State>, BiPredicate<? super State, ? super FlowableEmitter<Out>>, BackpressureStrategy, int) - Static method in class com.github.davidmoten.rx2.internal.flowable.TransformerStateMachine
 
create() - Method in class com.github.davidmoten.rx2.IO.ServerSocketBuilder
 
create() - Static method in class com.github.davidmoten.rx2.Statistics
 
create(T, S) - Static method in class com.github.davidmoten.rx2.util.Pair
 
create(int) - Static method in class com.github.davidmoten.util.RingBuffer
 
createInputStream(Publisher<String>, Charset) - Static method in class com.github.davidmoten.rx2.internal.flowable.FlowableStringInputStream
 
createWorker() - Method in class com.github.davidmoten.rx2.internal.SchedulerWithId
 

D

DataSerializer<T> - Interface in com.github.davidmoten.rx2.buffertofile
 
decode(CharsetDecoder, BackpressureStrategy, int) - Static method in class com.github.davidmoten.rx2.internal.flowable.TransformerDecode
 
decode(CharsetDecoder) - Static method in class com.github.davidmoten.rx2.Strings
 
decode(CharsetDecoder, BackpressureStrategy, int) - Static method in class com.github.davidmoten.rx2.Strings
 
decode(Flowable<byte[]>, CharsetDecoder) - Static method in class com.github.davidmoten.rx2.Strings
 
decode(Flowable<byte[]>, Charset) - Static method in class com.github.davidmoten.rx2.Strings
 
decode(Flowable<byte[]>, String) - Static method in class com.github.davidmoten.rx2.Strings
 
decrement(AtomicInteger) - Static method in class com.github.davidmoten.rx2.Consumers
 
DEFAULT_FILE_PREFIX - Static variable in class com.github.davidmoten.rx2.buffertofile.Options
 
delay(Long, TimeUnit) - Method in class com.github.davidmoten.rx2.RetryWhen.Builder
 
delay(long, TimeUnit) - Static method in class com.github.davidmoten.rx2.RetryWhen
 
delayErrors(boolean) - Method in class com.github.davidmoten.rx2.Flowables.MergeInterleaveBuilder
 
delays(Flowable<Long>, TimeUnit) - Method in class com.github.davidmoten.rx2.RetryWhen.Builder
 
delays(Flowable<Long>, TimeUnit) - Static method in class com.github.davidmoten.rx2.RetryWhen
 
delaysInt(Flowable<Integer>, TimeUnit) - Method in class com.github.davidmoten.rx2.RetryWhen.Builder
 
delaysInt(Flowable<Integer>, TimeUnit) - Static method in class com.github.davidmoten.rx2.RetryWhen
 
DelimitedStringLinkedList - Class in com.github.davidmoten.rx2.internal.flowable
Enables a forward-only iteration of string values split by a delimiter across a linked list of strings.
DelimitedStringLinkedList(String) - Constructor for class com.github.davidmoten.rx2.internal.flowable.DelimitedStringLinkedList
 
deserialize(DataInput) - Method in interface com.github.davidmoten.rx2.buffertofile.DataSerializer
 
deserialize(byte[]) - Method in interface com.github.davidmoten.rx2.buffertofile.Serializer
Returns a non-null instance of T from the byte array of length > 0.
deserialize(byte[]) - Method in class com.github.davidmoten.rx2.buffertofile.SerializerString
 
deserialize(byte[]) - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.SerializerBytes
 
deserialize(byte[]) - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.SerializerJavaIO
 
doNothing() - Static method in class com.github.davidmoten.rx2.Actions
 
doNothing() - Static method in class com.github.davidmoten.rx2.Consumers
 
doOnEmpty(Action) - Static method in class com.github.davidmoten.rx2.flowable.Transformers
Returns a transformer that when a stream is empty runs the given Action.
durationMs() - Method in class com.github.davidmoten.rx2.RetryWhen.ErrorAndDuration
 

E

element() - Method in class com.github.davidmoten.util.RingBuffer
 
equals(Object) - Method in class com.github.davidmoten.rx2.util.Pair
 
error(Throwable) - Method in class com.github.davidmoten.rx2.flowable.Burst.Builder
 
ErrorAndDuration(Throwable, long) - Constructor for class com.github.davidmoten.rx2.RetryWhen.ErrorAndDuration
 
errored(StateMachine.Errored<State, Out>) - Method in class com.github.davidmoten.rx2.StateMachine2.Builder3
 
exponentialBackoff(long, long, TimeUnit, double) - Method in class com.github.davidmoten.rx2.RetryWhen.Builder
 
exponentialBackoff(long, TimeUnit, double) - Method in class com.github.davidmoten.rx2.RetryWhen.Builder
 
exponentialBackoff(long, TimeUnit) - Method in class com.github.davidmoten.rx2.RetryWhen.Builder
 
exponentialBackoff(long, TimeUnit, double) - Static method in class com.github.davidmoten.rx2.RetryWhen
 
exponentialBackoff(long, TimeUnit) - Static method in class com.github.davidmoten.rx2.RetryWhen
 

F

failWhenInstanceOf(Class<? extends Throwable>...) - Method in class com.github.davidmoten.rx2.RetryWhen.Builder
 
failWhenInstanceOf(Class<? extends Throwable>...) - Static method in class com.github.davidmoten.rx2.RetryWhen
 
fetchPagesByRequest(BiFunction<? super Long, ? super Long, ? extends Flowable<T>>, long, int) - Static method in class com.github.davidmoten.rx2.Flowables
Creates a Flowable that is aimed at supporting calls to a service that provides data in pages where the page sizes are determined by requests from downstream (requests are a part of the backpressure machinery of RxJava).
fetchPagesByRequest(BiFunction<? super Long, ? super Long, ? extends Flowable<T>>, long) - Static method in class com.github.davidmoten.rx2.Flowables
 
fetchPagesByRequest(BiFunction<? super Long, ? super Long, ? extends Flowable<T>>) - Static method in class com.github.davidmoten.rx2.Flowables
 
fileFactory(Callable<File>) - Method in class com.github.davidmoten.rx2.buffertofile.Options.BuilderFlowable
Sets the file factory to be used by the queue storage mechanism.
fileFactory(Callable<File>) - Method in class com.github.davidmoten.rx2.buffertofile.Options.BuilderObservable
Sets the file factory to be used by the queue storage mechanism.
fileFactory() - Method in class com.github.davidmoten.rx2.buffertofile.Options
 
flatMapInterleaved(Function<? super T, ? extends Publisher<? extends R>>, int) - Static method in class com.github.davidmoten.rx2.flowable.Transformers
 
flatMapInterleaved(Function<? super T, ? extends Publisher<? extends R>>, int, int, boolean) - Static method in class com.github.davidmoten.rx2.flowable.Transformers
 
flowable() - Method in class com.github.davidmoten.rx2.flowable.CloseableFlowableWithReset
 
FlowableCollectWhile<T,R> - Class in com.github.davidmoten.rx2.internal.flowable
 
FlowableCollectWhile(Flowable<T>, Callable<R>, BiFunction<? super R, ? super T, ? extends R>, BiPredicate<? super R, ? super T>, boolean) - Constructor for class com.github.davidmoten.rx2.internal.flowable.FlowableCollectWhile
 
FlowableDoOnEmpty<T> - Class in com.github.davidmoten.rx2.internal.flowable
Calls a consumer just before completion if the stream was empty.
FlowableDoOnEmpty(Publisher<T>, Action) - Constructor for class com.github.davidmoten.rx2.internal.flowable.FlowableDoOnEmpty
 
FlowableFetchPagesByRequest - Class in com.github.davidmoten.rx2.internal.flowable
 
FlowableInsertMaybe<T> - Class in com.github.davidmoten.rx2.internal.flowable
 
FlowableInsertMaybe(Flowable<T>, Function<? super T, ? extends Maybe<? extends T>>) - Constructor for class com.github.davidmoten.rx2.internal.flowable.FlowableInsertMaybe
 
FlowableInsertTimeout<T> - Class in com.github.davidmoten.rx2.internal.flowable
 
FlowableInsertTimeout(Flowable<T>, Function<? super T, ? extends Long>, TimeUnit, Function<? super T, ? extends T>, Scheduler) - Constructor for class com.github.davidmoten.rx2.internal.flowable.FlowableInsertTimeout
 
FlowableMapLast<T> - Class in com.github.davidmoten.rx2.internal.flowable
 
FlowableMapLast(Flowable<T>, Function<? super T, ? extends T>) - Constructor for class com.github.davidmoten.rx2.internal.flowable.FlowableMapLast
 
FlowableMatch<A,B,K,C> - Class in com.github.davidmoten.rx2.internal.flowable
 
FlowableMatch(Flowable<A>, Flowable<B>, Function<? super A, ? extends K>, Function<? super B, ? extends K>, BiFunction<? super A, ? super B, C>, long) - Constructor for class com.github.davidmoten.rx2.internal.flowable.FlowableMatch
 
FlowableMaxRequest<T> - Class in com.github.davidmoten.rx2.internal.flowable
 
FlowableMaxRequest(Flowable<T>, long[]) - Constructor for class com.github.davidmoten.rx2.internal.flowable.FlowableMaxRequest
 
FlowableMergeInterleave<T> - Class in com.github.davidmoten.rx2.internal.flowable
 
FlowableMergeInterleave(Publisher<? extends Publisher<? extends T>>, int, int, boolean) - Constructor for class com.github.davidmoten.rx2.internal.flowable.FlowableMergeInterleave
 
FlowableMinRequest<T> - Class in com.github.davidmoten.rx2.internal.flowable
 
FlowableMinRequest(Flowable<T>, int[]) - Constructor for class com.github.davidmoten.rx2.internal.flowable.FlowableMinRequest
 
FlowableOnBackpressureBufferToFile<T> - Class in com.github.davidmoten.rx2.internal.flowable.buffertofile
 
FlowableOnBackpressureBufferToFile(Flowable<T>, Observable<T>, Options, Serializer<T>) - Constructor for class com.github.davidmoten.rx2.internal.flowable.buffertofile.FlowableOnBackpressureBufferToFile
 
FlowableOnBackpressureBufferToFile.BufferToFileSubscriberFlowable<T> - Class in com.github.davidmoten.rx2.internal.flowable.buffertofile
 
FlowableRepeat<T> - Class in com.github.davidmoten.rx2.internal.flowable
 
FlowableRepeat(T, long) - Constructor for class com.github.davidmoten.rx2.internal.flowable.FlowableRepeat
 
FlowableRepeatingTransform<T> - Class in com.github.davidmoten.rx2.internal.flowable
 
FlowableRepeatingTransform(Flowable<T>, Function<? super Flowable<T>, ? extends Flowable<T>>, int, long, Function<Observable<T>, Observable<?>>) - Constructor for class com.github.davidmoten.rx2.internal.flowable.FlowableRepeatingTransform
 
FlowableReverse - Class in com.github.davidmoten.rx2.internal.flowable
 
Flowables - Class in com.github.davidmoten.rx2
 
Flowables.MergeInterleaveBuilder<T> - Class in com.github.davidmoten.rx2
 
FlowableServerSocket - Class in com.github.davidmoten.rx2.internal.flowable
 
FlowableStateMachine<State,In,Out> - Class in com.github.davidmoten.rx2.internal.flowable
 
FlowableStateMachine(Flowable<In>, Callable<? extends State>, Function3<? super State, ? super In, ? super StateMachine.Emitter<Out>, ? extends State>, BiConsumer<? super State, ? super StateMachine.Emitter<Out>>, Consumer3<? super State, ? super Throwable, ? super StateMachine.Emitter<Out>>, BackpressureStrategy, int) - Constructor for class com.github.davidmoten.rx2.internal.flowable.FlowableStateMachine
 
FlowableStringInputStream - Class in com.github.davidmoten.rx2.internal.flowable
 
FlowableStringSplitSimple - Class in com.github.davidmoten.rx2.internal.flowable
 
FlowableStringSplitSimple(Flowable<String>, String) - Constructor for class com.github.davidmoten.rx2.internal.flowable.FlowableStringSplitSimple
 
FlowableWindowMinMax<T> - Class in com.github.davidmoten.rx2.internal.flowable
Uses a double-ended queue and collapses entries when they are redundant (whenever a value is added to the queue all values at the end of the queue that are greater or equal to that value are removed).
FlowableWindowMinMax(Flowable<T>, int, Comparator<? super T>, FlowableWindowMinMax.Metric) - Constructor for class com.github.davidmoten.rx2.internal.flowable.FlowableWindowMinMax
 
FlowableWindowMinMax.Metric - Enum in com.github.davidmoten.rx2.internal.flowable
 
from(DataSerializer<T>) - Static method in class com.github.davidmoten.rx2.buffertofile.Serializers
 
from(InputStream, int) - Static method in class com.github.davidmoten.rx2.Bytes
Returns a Flowable stream of byte arrays from the given InputStream between 1 and bufferSize bytes.
from(File) - Static method in class com.github.davidmoten.rx2.Bytes
 
from(File, int) - Static method in class com.github.davidmoten.rx2.Bytes
 
from(InputStream) - Static method in class com.github.davidmoten.rx2.Bytes
Returns a Flowable stream of byte arrays from the given InputStream of 8192 bytes.
from(Reader, int) - Static method in class com.github.davidmoten.rx2.Strings
 
from(Reader) - Static method in class com.github.davidmoten.rx2.Strings
 
from(InputStream) - Static method in class com.github.davidmoten.rx2.Strings
 
from(InputStream, Charset) - Static method in class com.github.davidmoten.rx2.Strings
 
from(InputStream, Charset, int) - Static method in class com.github.davidmoten.rx2.Strings
 
from(File) - Static method in class com.github.davidmoten.rx2.Strings
 
from(File, Charset) - Static method in class com.github.davidmoten.rx2.Strings
 
from(Callable<Reader>) - Static method in class com.github.davidmoten.rx2.Strings
 
fromClasspath(Class<?>, String, Charset) - Static method in class com.github.davidmoten.rx2.Strings
 
fromClasspath(String, Charset) - Static method in class com.github.davidmoten.rx2.Strings
 
fromClasspath(String) - Static method in class com.github.davidmoten.rx2.Strings
 
fromNullable(T) - Static method in class com.github.davidmoten.rx2.Maybes
 
Functions - Class in com.github.davidmoten.rx2
 

G

get(byte[], int, int, int) - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.Page
 
get(int) - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.Pages
 
getByte(long) - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.MemoryMappedFile
 
getByte(int) - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.Page
 
getByte() - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.Pages
 
getBytes(long, byte[], long, long) - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.MemoryMappedFile
 
getComment() - Method in class com.github.davidmoten.rx2.util.ZippedEntry
 
getCompressedSize() - Method in class com.github.davidmoten.rx2.util.ZippedEntry
 
getCrc() - Method in class com.github.davidmoten.rx2.util.ZippedEntry
 
getExtra() - Method in class com.github.davidmoten.rx2.util.ZippedEntry
 
getInputStream() - Method in class com.github.davidmoten.rx2.util.ZippedEntry
 
getInt(long) - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.MemoryMappedFile
 
getInt(int) - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.Page
 
getInt() - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.Pages
 
getIntVolatile(long) - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.MemoryMappedFile
 
getIntVolatile(int) - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.Page
 
getIntVolatile() - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.Pages
 
getMethod() - Method in class com.github.davidmoten.rx2.util.ZippedEntry
 
getName() - Method in class com.github.davidmoten.rx2.util.ZippedEntry
 
getSize() - Method in class com.github.davidmoten.rx2.util.ZippedEntry
 
getTime() - Method in class com.github.davidmoten.rx2.util.ZippedEntry
 

H

hashCode() - Method in class com.github.davidmoten.rx2.util.Pair
 

I

identity() - Static method in class com.github.davidmoten.rx2.Functions
 
increment(AtomicInteger) - Static method in class com.github.davidmoten.rx2.Actions
 
increment(AtomicInteger) - Static method in class com.github.davidmoten.rx2.Consumers
 
initialState(State) - Method in class com.github.davidmoten.rx2.StateMachine.Builder
 
initialState(State) - Method in class com.github.davidmoten.rx2.StateMachine2.Builder
 
initialStateFactory(Callable<State>) - Method in class com.github.davidmoten.rx2.StateMachine.Builder
 
initialStateFactory(Callable<State>) - Method in class com.github.davidmoten.rx2.StateMachine2.Builder
 
insert(Function<? super T, ? extends Maybe<? extends T>>) - Static method in class com.github.davidmoten.rx2.flowable.Transformers
For every onNext emission from the source stream, the valueToInsert Maybe is subscribed to.
insert(long, TimeUnit, T) - Static method in class com.github.davidmoten.rx2.flowable.Transformers
 
insert(Function<? super T, ? extends Long>, TimeUnit, T) - Static method in class com.github.davidmoten.rx2.flowable.Transformers
 
insert(Function<? super T, ? extends Long>, TimeUnit, Function<? super T, ? extends T>) - Static method in class com.github.davidmoten.rx2.flowable.Transformers
 
insert(Function<? super T, ? extends Long>, TimeUnit, Function<? super T, ? extends T>, Scheduler) - Static method in class com.github.davidmoten.rx2.flowable.Transformers
 
insert(Maybe<? extends T>) - Static method in class com.github.davidmoten.rx2.flowable.Transformers
 
IO - Class in com.github.davidmoten.rx2
 
IO.ServerSocketBuilder - Class in com.github.davidmoten.rx2
 
isEmpty() - Method in class com.github.davidmoten.util.RingBuffer
 
item(T) - Static method in class com.github.davidmoten.rx2.flowable.Burst
 
items(T...) - Static method in class com.github.davidmoten.rx2.flowable.Burst
 
iterator() - Method in class com.github.davidmoten.util.RingBuffer
 

J

javaIO() - Static method in class com.github.davidmoten.rx2.buffertofile.Serializers
 
join(Flowable<String>) - Static method in class com.github.davidmoten.rx2.Strings
 
join(Flowable<String>, String) - Static method in class com.github.davidmoten.rx2.Strings
 
join(String) - Static method in class com.github.davidmoten.rx2.Strings
 
join() - Static method in class com.github.davidmoten.rx2.Strings
 

K

kryo() - Static method in class com.github.davidmoten.rx2.flowable.Serialized
 
kryo(Kryo) - Static method in class com.github.davidmoten.rx2.flowable.Serialized
 

L

left() - Method in class com.github.davidmoten.rx2.util.Pair
 
length() - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.Page
 

M

mapLast(Function<? super T, ? extends T>) - Static method in class com.github.davidmoten.rx2.flowable.Transformers
 
markForRewriteAndAdvance4Bytes() - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.Pages
 
match(Flowable<A>, Flowable<B>, Function<? super A, K>, Function<? super B, K>, BiFunction<? super A, ? super B, C>, int) - Static method in class com.github.davidmoten.rx2.flowable.Transformers
 
match(Flowable<A>, Flowable<B>, Function<? super A, K>, Function<? super B, K>, BiFunction<? super A, ? super B, C>, int) - Static method in class com.github.davidmoten.rx2.Flowables
 
match(Flowable<A>, Flowable<B>, Function<? super A, K>, Function<? super B, K>, BiFunction<? super A, ? super B, C>) - Static method in class com.github.davidmoten.rx2.Flowables
 
matchWith(Flowable<B>, Function<? super A, K>, Function<? super B, K>, BiFunction<? super A, ? super B, C>, int) - Static method in class com.github.davidmoten.rx2.flowable.Transformers
 
matchWith(Flowable<B>, Function<? super A, K>, Function<? super B, K>, BiFunction<? super A, ? super B, C>) - Static method in class com.github.davidmoten.rx2.flowable.Transformers
 
maxConcurrency(int) - Method in class com.github.davidmoten.rx2.Flowables.MergeInterleaveBuilder
 
maxRequest(long...) - Static method in class com.github.davidmoten.rx2.flowable.Transformers
 
maxRetries(int) - Method in class com.github.davidmoten.rx2.RetryWhen.Builder
 
maxRetries(int) - Static method in class com.github.davidmoten.rx2.RetryWhen
 
maxSize() - Method in class com.github.davidmoten.util.RingBuffer
 
Maybes - Class in com.github.davidmoten.rx2
 
mean() - Method in class com.github.davidmoten.rx2.Statistics
 
MemoryMappedFile - Class in com.github.davidmoten.rx2.internal.flowable.buffertofile
 
MemoryMappedFile(File, long) - Constructor for class com.github.davidmoten.rx2.internal.flowable.buffertofile.MemoryMappedFile
 
mergeInterleaved(Publisher<? extends Publisher<? extends T>>, int, int, boolean) - Static method in class com.github.davidmoten.rx2.Flowables
 
mergeInterleaved(Publisher<? extends Publisher<? extends T>>, int) - Static method in class com.github.davidmoten.rx2.Flowables
 
mergeInterleaved(Publisher<? extends Publisher<? extends T>>) - Static method in class com.github.davidmoten.rx2.Flowables
 
minRequest(int...) - Static method in class com.github.davidmoten.rx2.flowable.Transformers
 
moveReadPosition(int) - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.Pages
 
moveWritePosition(int) - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.Pages
 

N

next() - Method in class com.github.davidmoten.rx2.internal.flowable.DelimitedStringLinkedList
 

O

observable() - Method in class com.github.davidmoten.rx2.observable.CloseableObservableWithReset
 
Observables - Class in com.github.davidmoten.rx2
 
offer(byte[]) - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.PagedQueue
 
offer(T) - Method in class com.github.davidmoten.util.RingBuffer
 
onBackpressureBufferToFile() - Static method in class com.github.davidmoten.rx2.flowable.Transformers
 
onBackpressureBufferToFile() - Static method in class com.github.davidmoten.rx2.observable.Transformers
 
onComplete() - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.FlowableOnBackpressureBufferToFile.BufferToFileSubscriberFlowable
 
onComplete_() - Method in interface com.github.davidmoten.rx2.StateMachine.Emitter
 
onError(Throwable) - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.FlowableOnBackpressureBufferToFile.BufferToFileSubscriberFlowable
 
onError_(Throwable) - Method in interface com.github.davidmoten.rx2.StateMachine.Emitter
 
onNext(T) - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.FlowableOnBackpressureBufferToFile.BufferToFileSubscriberFlowable
 
onNext_(T) - Method in interface com.github.davidmoten.rx2.StateMachine.Emitter
 
onSubscribe(Subscription) - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.FlowableOnBackpressureBufferToFile.BufferToFileSubscriberFlowable
 
OnSubscribeCacheResetable<T> - Class in com.github.davidmoten.rx2.internal.observable
 
OnSubscribeCacheResetable(Observable<T>) - Constructor for class com.github.davidmoten.rx2.internal.observable.OnSubscribeCacheResetable
 
OnSubscribeCacheResettable<T> - Class in com.github.davidmoten.rx2.internal.flowable
 
OnSubscribeCacheResettable(Flowable<T>) - Constructor for class com.github.davidmoten.rx2.internal.flowable.OnSubscribeCacheResettable
 
Options - Class in com.github.davidmoten.rx2.buffertofile
 
Options.BuilderFlowable - Class in com.github.davidmoten.rx2.buffertofile
 
Options.BuilderObservable - Class in com.github.davidmoten.rx2.buffertofile
 

P

Page - Class in com.github.davidmoten.rx2.internal.flowable.buffertofile
 
Page(File, int) - Constructor for class com.github.davidmoten.rx2.internal.flowable.buffertofile.Page
 
PagedQueue - Class in com.github.davidmoten.rx2.internal.flowable.buffertofile
 
PagedQueue(Callable<File>, int) - Constructor for class com.github.davidmoten.rx2.internal.flowable.buffertofile.PagedQueue
 
Pages - Class in com.github.davidmoten.rx2.internal.flowable.buffertofile
 
Pages(Callable<File>, int) - Constructor for class com.github.davidmoten.rx2.internal.flowable.buffertofile.Pages
 
pageSizeBytes(int) - Method in class com.github.davidmoten.rx2.buffertofile.Options.BuilderFlowable
Sets the page size in bytes.
pageSizeBytes(int) - Method in class com.github.davidmoten.rx2.buffertofile.Options.BuilderObservable
Sets the page size in bytes.
pageSizeBytes() - Method in class com.github.davidmoten.rx2.buffertofile.Options
 
Pair<T,S> - Class in com.github.davidmoten.rx2.util
 
Pair(T, S) - Constructor for class com.github.davidmoten.rx2.util.Pair
 
peek() - Method in class com.github.davidmoten.util.RingBuffer
 
poll() - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.PagedQueue
 
poll() - Method in class com.github.davidmoten.util.RingBuffer
 
preAcceptAction(Action) - Method in class com.github.davidmoten.rx2.IO.ServerSocketBuilder
 
Predicates - Class in com.github.davidmoten.rx2
 
println() - Static method in class com.github.davidmoten.rx2.Consumers
 
printLong(String) - Static method in class com.github.davidmoten.rx2.Consumers
 
printStackTrace() - Static method in class com.github.davidmoten.rx2.Consumers
 
process(byte[], ByteBuffer, boolean, CharsetDecoder, FlowableEmitter<String>) - Static method in class com.github.davidmoten.rx2.internal.flowable.TransformerDecode
 
put(int, byte[], int, int) - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.Page
 
put(byte[], int, int) - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.Pages
 
putByte(long, byte) - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.MemoryMappedFile
 
putByte(int, byte) - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.Page
 
putByte(byte) - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.Pages
 
putBytes(long, byte[], long, long) - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.MemoryMappedFile
 
putInt(long, int) - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.MemoryMappedFile
 
putInt(int, int) - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.Page
 
putInt(int) - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.Pages
 
putIntOrdered(int, int) - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.Page
 
putIntOrderedAtRewriteMark(int) - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.Pages
 
putOrderedInt(long, int) - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.MemoryMappedFile
 

R

read(Class<T>, File) - Method in class com.github.davidmoten.rx2.flowable.Serialized.KryoBuilder
 
read(Class<T>, File, int) - Method in class com.github.davidmoten.rx2.flowable.Serialized.KryoBuilder
 
read(Class<T>, Input) - Method in class com.github.davidmoten.rx2.flowable.Serialized.KryoBuilder
 
read(ObjectInputStream) - Static method in class com.github.davidmoten.rx2.flowable.Serialized
Returns the deserialized objects from the given InputStream as a Flowable stream.
read(File, int) - Static method in class com.github.davidmoten.rx2.flowable.Serialized
Returns the deserialized objects from the given File as a Flowable stream.
read(File) - Static method in class com.github.davidmoten.rx2.flowable.Serialized
Returns the deserialized objects from the given File as a Flowable stream.
readTimeoutMs(int) - Method in class com.github.davidmoten.rx2.IO.ServerSocketBuilder
 
rebatchRequests(int, long, boolean) - Static method in class com.github.davidmoten.rx2.flowable.Transformers
 
rebatchRequests(int, long) - Static method in class com.github.davidmoten.rx2.flowable.Transformers
 
reduce(Function<? super Flowable<T>, ? extends Flowable<T>>, int, long) - Static method in class com.github.davidmoten.rx2.flowable.Transformers
 
reduce(Function<? super Flowable<T>, ? extends Flowable<T>>, int) - Static method in class com.github.davidmoten.rx2.flowable.Transformers
 
remaining() - Method in class com.github.davidmoten.rx2.internal.flowable.DelimitedStringLinkedList
 
remove(Object) - Method in class com.github.davidmoten.util.RingBuffer
 
remove() - Method in class com.github.davidmoten.util.RingBuffer
 
removeAll(Collection<?>) - Method in class com.github.davidmoten.util.RingBuffer
 
repeat(Function<? super Flowable<T>, ? extends Flowable<T>>, int, long, Function<Observable<T>, Observable<?>>) - Static method in class com.github.davidmoten.rx2.flowable.Transformers
 
repeat(T) - Static method in class com.github.davidmoten.rx2.Flowables
 
repeat(T, long) - Static method in class com.github.davidmoten.rx2.Flowables
 
request(long) - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.FlowableOnBackpressureBufferToFile.BufferToFileSubscriberFlowable
 
requestBatchSize(int) - Method in class com.github.davidmoten.rx2.StateMachine.Builder3
 
requestBatchSize(int) - Method in class com.github.davidmoten.rx2.StateMachine2.Builder3
 
reset() - Method in class com.github.davidmoten.rx2.flowable.CachedFlowable
 
reset() - Method in class com.github.davidmoten.rx2.flowable.CloseableFlowableWithReset
 
reset() - Method in class com.github.davidmoten.rx2.internal.flowable.OnSubscribeCacheResettable
 
reset() - Method in class com.github.davidmoten.rx2.internal.observable.OnSubscribeCacheResetable
 
reset() - Method in class com.github.davidmoten.rx2.observable.CachedObservable
 
reset() - Method in class com.github.davidmoten.rx2.observable.CloseableObservableWithReset
 
retainAll(Collection<?>) - Method in class com.github.davidmoten.util.RingBuffer
 
retryIf(Predicate<Throwable>) - Method in class com.github.davidmoten.rx2.RetryWhen.Builder
 
retryIf(Predicate<Throwable>) - Static method in class com.github.davidmoten.rx2.RetryWhen
 
RetryWhen - Class in com.github.davidmoten.rx2
Provides builder for the Function parameter of Flowable.retryWhen(Function).
RetryWhen.Builder - Class in com.github.davidmoten.rx2
 
RetryWhen.ErrorAndDuration - Class in com.github.davidmoten.rx2
 
retryWhenInstanceOf(Class<? extends Throwable>...) - Method in class com.github.davidmoten.rx2.RetryWhen.Builder
 
retryWhenInstanceOf(Class<? extends Throwable>...) - Static method in class com.github.davidmoten.rx2.RetryWhen
 
reverse() - Static method in class com.github.davidmoten.rx2.flowable.Transformers
 
reverse(Flowable<T>) - Static method in class com.github.davidmoten.rx2.internal.flowable.FlowableReverse
 
right() - Method in class com.github.davidmoten.rx2.util.Pair
 
RingBuffer<T> - Class in com.github.davidmoten.util
Non-threadsafe implementation of a Ring Buffer.

S

scheduler(Scheduler) - Method in class com.github.davidmoten.rx2.buffertofile.Options.BuilderFlowable
Sets the scheduler to use for reading items from files and emitting them.
scheduler(Scheduler) - Method in class com.github.davidmoten.rx2.buffertofile.Options.BuilderObservable
Sets the scheduler to use for reading items from files and emitting them.
scheduler() - Method in class com.github.davidmoten.rx2.buffertofile.Options
 
scheduler(Scheduler) - Method in class com.github.davidmoten.rx2.RetryWhen.Builder
 
scheduler(Scheduler) - Static method in class com.github.davidmoten.rx2.RetryWhen
 
SchedulerHelper - Class in com.github.davidmoten.rx2
 
SchedulerWithId - Class in com.github.davidmoten.rx2.internal
 
SchedulerWithId(Scheduler, String) - Constructor for class com.github.davidmoten.rx2.internal.SchedulerWithId
 
sd() - Method in class com.github.davidmoten.rx2.Statistics
 
serialize(T, DataOutput) - Method in interface com.github.davidmoten.rx2.buffertofile.DataSerializer
 
serialize(T) - Method in interface com.github.davidmoten.rx2.buffertofile.Serializer
Returns a byte array of length > 0 that is the serialization of the given value.
serialize(String) - Method in class com.github.davidmoten.rx2.buffertofile.SerializerString
 
serialize(byte[]) - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.SerializerBytes
 
serialize(Serializable) - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.SerializerJavaIO
 
Serialized - Class in com.github.davidmoten.rx2.flowable
Utility class for writing Flowable streams to ObjectOutputStreams and reading Flowable streams of indeterminate size from ObjectInputStreams.
Serialized.KryoBuilder - Class in com.github.davidmoten.rx2.flowable
 
serializer(Serializer<T>) - Method in class com.github.davidmoten.rx2.buffertofile.Options.BuilderFlowable
 
serializer(DataSerializer<T>) - Method in class com.github.davidmoten.rx2.buffertofile.Options.BuilderFlowable
 
serializer(Serializer<T>) - Method in class com.github.davidmoten.rx2.buffertofile.Options.BuilderObservable
 
serializer(DataSerializer<T>) - Method in class com.github.davidmoten.rx2.buffertofile.Options.BuilderObservable
 
Serializer<T> - Interface in com.github.davidmoten.rx2.buffertofile
 
serializerBytes() - Method in class com.github.davidmoten.rx2.buffertofile.Options.BuilderFlowable
Returns a Flowable Transformer that buffers items to disk (files).
serializerBytes() - Method in class com.github.davidmoten.rx2.buffertofile.Options.BuilderObservable
Returns a Flowable Transformer that buffers items to disk (files).
SerializerBytes - Class in com.github.davidmoten.rx2.internal.flowable.buffertofile
 
SerializerBytes() - Constructor for class com.github.davidmoten.rx2.internal.flowable.buffertofile.SerializerBytes
 
serializerJavaIO() - Method in class com.github.davidmoten.rx2.buffertofile.Options.BuilderFlowable
Returns a Flowable Transformer to buffer stream items to disk (files).
serializerJavaIO() - Method in class com.github.davidmoten.rx2.buffertofile.Options.BuilderObservable
Returns a Flowable Transformer to buffer stream items to disk (files).
SerializerJavaIO<T extends Serializable> - Class in com.github.davidmoten.rx2.internal.flowable.buffertofile
 
SerializerJavaIO() - Constructor for class com.github.davidmoten.rx2.internal.flowable.buffertofile.SerializerJavaIO
 
Serializers - Class in com.github.davidmoten.rx2.buffertofile
 
SerializerString - Class in com.github.davidmoten.rx2.buffertofile
 
SerializerString(Charset) - Constructor for class com.github.davidmoten.rx2.buffertofile.SerializerString
 
serializerUtf8() - Method in class com.github.davidmoten.rx2.buffertofile.Options.BuilderFlowable
 
serializerUtf8() - Method in class com.github.davidmoten.rx2.buffertofile.Options.BuilderObservable
 
serverSocket(int) - Static method in class com.github.davidmoten.rx2.IO
 
serverSocket(Callable<? extends ServerSocket>) - Static method in class com.github.davidmoten.rx2.IO
 
serverSocketAutoAllocatePort(Consumer<Integer>) - Static method in class com.github.davidmoten.rx2.IO
 
ServerSocketBuilder(Callable<? extends ServerSocket>) - Constructor for class com.github.davidmoten.rx2.IO.ServerSocketBuilder
 
set(AtomicReference<T>) - Static method in class com.github.davidmoten.rx2.Consumers
 
set(AtomicInteger) - Static method in class com.github.davidmoten.rx2.Consumers
 
setToTrue(AtomicBoolean) - Static method in class com.github.davidmoten.rx2.Actions
 
setToTrue(AtomicBoolean) - Static method in class com.github.davidmoten.rx2.Consumers
 
size() - Method in class com.github.davidmoten.util.RingBuffer
 
sizeHint() - Method in interface com.github.davidmoten.rx2.buffertofile.DataSerializer
Returns 0 to indicate unknown (unbounded) capacity.
split(String, Pattern, BackpressureStrategy, int) - Static method in class com.github.davidmoten.rx2.internal.flowable.TransformerStringSplit
 
split(Flowable<String>, String) - Static method in class com.github.davidmoten.rx2.Strings
 
split(String) - Static method in class com.github.davidmoten.rx2.Strings
 
split(Pattern) - Static method in class com.github.davidmoten.rx2.Strings
 
split(String, BackpressureStrategy, int) - Static method in class com.github.davidmoten.rx2.Strings
 
split(Pattern, BackpressureStrategy, int) - Static method in class com.github.davidmoten.rx2.Strings
 
splitLinesSkipComments(InputStream, Charset, String, String) - Static method in class com.github.davidmoten.rx2.Strings
 
splitSimple(String) - Static method in class com.github.davidmoten.rx2.Strings
Splits on a string delimiter, not a pattern.
stateMachine(Callable<? extends State>, Function3<? super State, ? super In, ? super FlowableEmitter<Out>, ? extends State>, BiPredicate<? super State, ? super FlowableEmitter<Out>>, BackpressureStrategy, int) - Static method in class com.github.davidmoten.rx2.flowable.Transformers
 
stateMachine() - Static method in class com.github.davidmoten.rx2.flowable.Transformers
 
StateMachine - Class in com.github.davidmoten.rx2
 
StateMachine.Builder - Class in com.github.davidmoten.rx2
 
StateMachine.Builder2<State> - Class in com.github.davidmoten.rx2
 
StateMachine.Builder3<State,In,Out> - Class in com.github.davidmoten.rx2
 
StateMachine.Completion<State,Out> - Interface in com.github.davidmoten.rx2
 
StateMachine.Completion2<State,Out> - Interface in com.github.davidmoten.rx2
 
StateMachine.Emitter<T> - Interface in com.github.davidmoten.rx2
 
StateMachine.Errored<State,Out> - Interface in com.github.davidmoten.rx2
 
StateMachine.Transition<State,In,Out> - Interface in com.github.davidmoten.rx2
 
StateMachine.Transition2<State,In,Out> - Interface in com.github.davidmoten.rx2
 
stateMachine2() - Static method in class com.github.davidmoten.rx2.flowable.Transformers
 
StateMachine2 - Class in com.github.davidmoten.rx2
 
StateMachine2() - Constructor for class com.github.davidmoten.rx2.StateMachine2
 
StateMachine2.Builder - Class in com.github.davidmoten.rx2
 
StateMachine2.Builder2<State> - Class in com.github.davidmoten.rx2
 
StateMachine2.Builder3<State,In,Out> - Class in com.github.davidmoten.rx2
 
Statistics - Class in com.github.davidmoten.rx2
 
string(Charset) - Static method in class com.github.davidmoten.rx2.buffertofile.Serializers
 
Strings - Class in com.github.davidmoten.rx2
 
strings(Flowable<?>) - Static method in class com.github.davidmoten.rx2.Strings
 
strings() - Static method in class com.github.davidmoten.rx2.Strings
 
subscribe(Subscriber<? super T>) - Method in class com.github.davidmoten.rx2.internal.flowable.OnSubscribeCacheResettable
 
subscribe(Observer<? super T>) - Method in class com.github.davidmoten.rx2.internal.observable.OnSubscribeCacheResetable
 
subscribeActual(Subscriber<? super T>) - Method in class com.github.davidmoten.rx2.flowable.Burst
 
subscribeActual(Subscriber<? super T>) - Method in class com.github.davidmoten.rx2.flowable.CachedFlowable
 
subscribeActual(Subscriber<? super T>) - Method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.FlowableOnBackpressureBufferToFile
 
subscribeActual(Subscriber<? super R>) - Method in class com.github.davidmoten.rx2.internal.flowable.FlowableCollectWhile
 
subscribeActual(Subscriber<? super T>) - Method in class com.github.davidmoten.rx2.internal.flowable.FlowableDoOnEmpty
 
subscribeActual(Subscriber<? super T>) - Method in class com.github.davidmoten.rx2.internal.flowable.FlowableInsertMaybe
 
subscribeActual(Subscriber<? super T>) - Method in class com.github.davidmoten.rx2.internal.flowable.FlowableInsertTimeout
 
subscribeActual(Subscriber<? super T>) - Method in class com.github.davidmoten.rx2.internal.flowable.FlowableMapLast
 
subscribeActual(Subscriber<? super C>) - Method in class com.github.davidmoten.rx2.internal.flowable.FlowableMatch
 
subscribeActual(Subscriber<? super T>) - Method in class com.github.davidmoten.rx2.internal.flowable.FlowableMaxRequest
 
subscribeActual(Subscriber<? super T>) - Method in class com.github.davidmoten.rx2.internal.flowable.FlowableMergeInterleave
 
subscribeActual(Subscriber<? super T>) - Method in class com.github.davidmoten.rx2.internal.flowable.FlowableMinRequest
 
subscribeActual(Subscriber<? super T>) - Method in class com.github.davidmoten.rx2.internal.flowable.FlowableRepeat
 
subscribeActual(Subscriber<? super T>) - Method in class com.github.davidmoten.rx2.internal.flowable.FlowableRepeatingTransform
 
subscribeActual(Subscriber<? super Out>) - Method in class com.github.davidmoten.rx2.internal.flowable.FlowableStateMachine
 
subscribeActual(Subscriber<? super String>) - Method in class com.github.davidmoten.rx2.internal.flowable.FlowableStringSplitSimple
 
subscribeActual(Subscriber<? super T>) - Method in class com.github.davidmoten.rx2.internal.flowable.FlowableWindowMinMax
 
subscribeActual(Observer<? super T>) - Method in class com.github.davidmoten.rx2.observable.CachedObservable
 
sum() - Method in class com.github.davidmoten.rx2.Statistics
 
sumSquares() - Method in class com.github.davidmoten.rx2.Statistics
 

T

test(State, FlowableEmitter<Out>) - Method in interface com.github.davidmoten.rx2.StateMachine.Completion
 
throwable() - Method in class com.github.davidmoten.rx2.RetryWhen.ErrorAndDuration
 
throwing(Exception) - Static method in class com.github.davidmoten.rx2.Actions
 
throwing() - Static method in class com.github.davidmoten.rx2.BiFunctions
 
throwing() - Static method in class com.github.davidmoten.rx2.BiPredicates
 
throwing() - Static method in class com.github.davidmoten.rx2.Functions
 
ThrowingException - Exception in com.github.davidmoten.rx2.exceptions
 
ThrowingException() - Constructor for exception com.github.davidmoten.rx2.exceptions.ThrowingException
 
toArray() - Method in class com.github.davidmoten.util.RingBuffer
 
toArray(S[]) - Method in class com.github.davidmoten.util.RingBuffer
 
toInputStream(Publisher<String>, Charset) - Static method in class com.github.davidmoten.rx2.Strings
Returns an InputStream that offers the concatenated String data emitted by a subscription to the given publisher using the given character set.
toInputStream(Publisher<String>) - Static method in class com.github.davidmoten.rx2.Strings
Returns an InputStream that offers the concatenated String data emitted by a subscription to the given publisher using the character set UTF-8 for the bytes read through the InputStream.
toListWhile(BiPredicate<? super List<T>, ? super T>, boolean) - Static method in class com.github.davidmoten.rx2.flowable.Transformers
 
toListWhile(BiPredicate<? super List<T>, ? super T>) - Static method in class com.github.davidmoten.rx2.flowable.Transformers
 
toNull() - Static method in class com.github.davidmoten.rx2.BiFunctions
 
toNull() - Static method in class com.github.davidmoten.rx2.Callables
 
toString() - Method in class com.github.davidmoten.rx2.Statistics
 
toString() - Method in class com.github.davidmoten.rx2.util.Pair
 
toString() - Method in class com.github.davidmoten.util.RingBuffer
 
toStringFunction() - Static method in class com.github.davidmoten.rx2.Functions
 
TransformerDecode - Class in com.github.davidmoten.rx2.internal.flowable
 
Transformers - Class in com.github.davidmoten.rx2.flowable
 
Transformers - Class in com.github.davidmoten.rx2.observable
 
TransformerStateMachine<State,In,Out> - Class in com.github.davidmoten.rx2.internal.flowable
 
TransformerStringSplit - Class in com.github.davidmoten.rx2.internal.flowable
 
transition(StateMachine.Transition<State, In, Out>) - Method in class com.github.davidmoten.rx2.StateMachine.Builder2
 
transition(StateMachine.Transition2<State, In, Out>) - Method in class com.github.davidmoten.rx2.StateMachine2.Builder2
 
trim() - Static method in class com.github.davidmoten.rx2.Strings
 

U

unsafe() - Static method in class com.github.davidmoten.rx2.internal.flowable.buffertofile.UnsafeAccess
 
UnsafeAccess - Class in com.github.davidmoten.rx2.internal.flowable.buffertofile
 
unzip(File) - Static method in class com.github.davidmoten.rx2.Bytes
 
unzip(InputStream) - Static method in class com.github.davidmoten.rx2.Bytes
 
unzip(ZipInputStream) - Static method in class com.github.davidmoten.rx2.Bytes
 
utf8() - Static method in class com.github.davidmoten.rx2.buffertofile.Serializers
 
UTF_8 - Static variable in class com.github.davidmoten.rx2.Strings
 

V

valueOf(String) - Static method in enum com.github.davidmoten.rx2.internal.flowable.FlowableWindowMinMax.Metric
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.github.davidmoten.rx2.internal.flowable.FlowableWindowMinMax.Metric
Returns an array containing the constants of this enum type, in the order they are declared.

W

windowMax(int) - Static method in class com.github.davidmoten.rx2.flowable.Transformers
 
windowMax(int, Comparator<? super T>) - Static method in class com.github.davidmoten.rx2.flowable.Transformers
 
windowMin(int) - Static method in class com.github.davidmoten.rx2.flowable.Transformers
 
windowMin(int, Comparator<? super T>) - Static method in class com.github.davidmoten.rx2.flowable.Transformers
 
withThreadId(Scheduler, String) - Static method in class com.github.davidmoten.rx2.SchedulerHelper
 
withThreadIdFromCallSite(Scheduler) - Static method in class com.github.davidmoten.rx2.SchedulerHelper
 
write(Flowable<T>, File) - Method in class com.github.davidmoten.rx2.flowable.Serialized.KryoBuilder
 
write(Flowable<T>, File, boolean) - Method in class com.github.davidmoten.rx2.flowable.Serialized.KryoBuilder
 
write(Flowable<T>, File, boolean, int) - Method in class com.github.davidmoten.rx2.flowable.Serialized.KryoBuilder
 
write(Flowable<T>, ObjectOutputStream) - Static method in class com.github.davidmoten.rx2.flowable.Serialized
Returns a duplicate of the input stream but with the side effect that emissions from the source are written to the ObjectOutputStream.
write(Flowable<T>, File, boolean, int) - Static method in class com.github.davidmoten.rx2.flowable.Serialized
Writes the source stream to the given file in given append mode and using the given buffer size.
write(Flowable<T>, File, boolean) - Static method in class com.github.davidmoten.rx2.flowable.Serialized
Writes the source stream to the given file in given append mode and using the a buffer size of 8192 bytes.
write(Flowable<T>, File) - Static method in class com.github.davidmoten.rx2.flowable.Serialized
Writes the source stream to the given file in given append mode and using the a buffer size of 8192 bytes.

Z

ZippedEntry - Class in com.github.davidmoten.rx2.util
 
ZippedEntry(ZipEntry, InputStream) - Constructor for class com.github.davidmoten.rx2.util.ZippedEntry
 

_

_1() - Method in class com.github.davidmoten.rx2.util.Pair
 
_2() - Method in class com.github.davidmoten.rx2.util.Pair
 
A B C D E F G H I J K L M N O P R S T U V W Z _ 
Skip navigation links

Copyright © 2013–2020. All rights reserved.