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

A

a() - Method in class com.github.davidmoten.rx.util.Pair
 
a0(Checked.A0) - Static method in class com.github.davidmoten.rx.Checked
 
a0(Checked.A0) - Static method in class com.github.davidmoten.rx.Ignore
 
a1(Checked.A1<T>) - Static method in class com.github.davidmoten.rx.Checked
 
a1(Checked.A1<T>) - Static method in class com.github.davidmoten.rx.Ignore
 
a2(Checked.A2<T, R>) - Static method in class com.github.davidmoten.rx.Checked
 
absent() - Static method in class com.github.davidmoten.util.Optional
 
acceptSocketIf(Func1<? super Socket, Boolean>) - Method in class com.github.davidmoten.rx.IO.ServerSocketBuilder
 
acceptTimeoutMs(int) - Method in class com.github.davidmoten.rx.IO.ServerSocketBuilder
 
action(Action1<? super RetryWhen.ErrorAndDuration>) - Method in class com.github.davidmoten.rx.RetryWhen
 
action(Action1<? super RetryWhen.ErrorAndDuration>) - Method in class com.github.davidmoten.rx.RetryWhen.Builder
 
Actions - Class in com.github.davidmoten.rx
 
add() - Static method in class com.github.davidmoten.rx.Functions
Returns a Func2 that adds numbers.
add(T) - Method in class com.github.davidmoten.rx.internal.operators.FileBasedSPSCQueueMemoryMapped
 
add(Number) - Method in class com.github.davidmoten.rx.Statistics
 
addAll(Collection<? extends T>) - Method in class com.github.davidmoten.rx.internal.operators.FileBasedSPSCQueueMemoryMapped
 
addTo(AtomicLong) - Static method in class com.github.davidmoten.rx.Actions
 
addTo(List<T>) - Static method in class com.github.davidmoten.rx.Actions
 
alwaysFalse() - Static method in class com.github.davidmoten.rx.Functions
 
alwaysFalse2() - Static method in class com.github.davidmoten.rx.Functions
 
alwaysTrue() - Static method in class com.github.davidmoten.rx.Functions
 
alwaysTrue2() - Static method in class com.github.davidmoten.rx.Functions
 
appendEnv() - Method in class com.github.davidmoten.rx.Processes.Parameters
 
assertCompleted() - Method in class com.github.davidmoten.rx.testing.TestSubscriber2
 
assertError(Class<? extends Throwable>) - Method in class com.github.davidmoten.rx.testing.TestSubscriber2
 
assertError(Throwable) - Method in class com.github.davidmoten.rx.testing.TestSubscriber2
 
AssertionException(String) - Constructor for exception com.github.davidmoten.rx.testing.TestingHelper.AssertionException
 
assertNoErrors() - Method in class com.github.davidmoten.rx.testing.TestSubscriber2
 
assertNotCompleted() - Method in class com.github.davidmoten.rx.testing.TestSubscriber2
 
assertNoTerminalEvent() - Method in class com.github.davidmoten.rx.testing.TestSubscriber2
 
assertNoValues() - Method in class com.github.davidmoten.rx.testing.TestSubscriber2
 
assertReceivedOnNext(List<T>) - Method in class com.github.davidmoten.rx.testing.TestSubscriber2
 
assertTerminalEvent() - Method in class com.github.davidmoten.rx.testing.TestSubscriber2
 
assertUnsubscribed() - Method in class com.github.davidmoten.rx.testing.TestSubscriber2
 
assertValue(T) - Method in class com.github.davidmoten.rx.testing.TestSubscriber2
 
assertValueCount(int) - Method in class com.github.davidmoten.rx.testing.TestSubscriber2
 
assertValues(T...) - Method in class com.github.davidmoten.rx.testing.TestSubscriber2
 
assertValuesAndClear(T, T...) - Method in class com.github.davidmoten.rx.testing.TestSubscriber2
 
awaitTerminalEvent() - Method in class com.github.davidmoten.rx.testing.TestSubscriber2
 
awaitTerminalEvent(long, TimeUnit) - Method in class com.github.davidmoten.rx.testing.TestSubscriber2
 
awaitTerminalEventAndUnsubscribeOnTimeout(long, TimeUnit) - Method in class com.github.davidmoten.rx.testing.TestSubscriber2
 
awaitValueCount(int, long, TimeUnit) - Method in class com.github.davidmoten.rx.testing.TestSubscriber2
 

B

b() - Method in class com.github.davidmoten.rx.util.Pair
 
backpressureStrategy(BackpressureStrategy) - Method in class com.github.davidmoten.rx.StateMachine.Builder3
 
BackpressureStrategy - Enum in com.github.davidmoten.rx.util
 
BackpressureUtils - Class in com.github.davidmoten.rx.util
Utility functions for use with backpressure.
blockUntilWorkFinished(Scheduler, int, long, TimeUnit) - Static method in class com.github.davidmoten.rx.Schedulers
 
blockUntilWorkFinished(Scheduler, int) - Static method in class com.github.davidmoten.rx.Schedulers
 
buf - Variable in class com.github.davidmoten.util.ByteArrayOutputStreamNoCopyUnsynchronized
The buffer where data is stored.
bufferSize(int) - Method in class com.github.davidmoten.rx.IO.ServerSocketBuilder
 
bufferSizeBytes() - Method in class com.github.davidmoten.rx.buffertofile.Options
 
bufferSizeBytes(int) - Static method in class com.github.davidmoten.rx.buffertofile.Options
 
bufferSizeBytes(int) - Method in class com.github.davidmoten.rx.buffertofile.Options.Builder
 
bufferUntil(Func1<? super T, Boolean>) - Static method in class com.github.davidmoten.rx.Transformers
Buffers the elements into continuous, non-overlapping Lists where the boundary is determined by a predicate receiving each item, after being buffered, and returns true to indicate a new buffer should start.
bufferUntil(Func1<? super T, Boolean>, int) - Static method in class com.github.davidmoten.rx.Transformers
Buffers the elements into continuous, non-overlapping Lists where the boundary is determined by a predicate receiving each item, after being buffered, and returns true to indicate a new buffer should start.
bufferWhile(Func1<? super T, Boolean>) - Static method in class com.github.davidmoten.rx.Transformers
Buffers the elements into continuous, non-overlapping Lists where the boundary is determined by a predicate receiving each item, before or after being buffered, and returns true to indicate a new buffer should start.
bufferWhile(Func1<? super T, Boolean>, int) - Static method in class com.github.davidmoten.rx.Transformers
Buffers the elements into continuous, non-overlapping Lists where the boundary is determined by a predicate receiving each item, before being buffered, and returns true to indicate a new buffer should start.
build() - Method in class com.github.davidmoten.rx.buffertofile.Options.Builder
 
build() - Method in class com.github.davidmoten.rx.RetryWhen.Builder
 
build() - Method in class com.github.davidmoten.rx.StateMachine.Builder3
 
builder() - Static method in class com.github.davidmoten.rx.StateMachine
 
byteArray() - Static method in class com.github.davidmoten.rx.buffertofile.DataSerializers
 
ByteArrayOutputStreamNoCopyUnsynchronized - Class in com.github.davidmoten.util
This class implements an output stream in which the data is written into a byte array.
ByteArrayOutputStreamNoCopyUnsynchronized() - Constructor for class com.github.davidmoten.util.ByteArrayOutputStreamNoCopyUnsynchronized
Creates a new byte array output stream.
ByteArrayOutputStreamNoCopyUnsynchronized(int) - Constructor for class com.github.davidmoten.util.ByteArrayOutputStreamNoCopyUnsynchronized
Creates a new byte array output stream, with a buffer capacity of the specified size, in bytes.
Bytes - Class in com.github.davidmoten.rx
 

C

cache(Observable<T>) - Static method in class com.github.davidmoten.rx.Obs
Returns a cached Observable like Observable.cache() except that the cache can be reset by calling CachedObservable.reset().
cache(Observable<T>, long, TimeUnit, Scheduler.Worker) - Static method in class com.github.davidmoten.rx.Obs
Returns a cached Observable like Observable.cache() except that the cache can be reset by calling CachedObservable.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.rx.Obs
Returns a cached Observable like Observable.cache() except that the cache may be reset by the user calling CloseableObservableWithReset.reset().
cache(long, TimeUnit, Scheduler.Worker) - Static method in class com.github.davidmoten.rx.Transformers
 
CachedObservable<T> - Class in com.github.davidmoten.rx.observables
 
CachedObservable(Observable<T>) - Constructor for class com.github.davidmoten.rx.observables.CachedObservable
 
CacheType - Enum in com.github.davidmoten.rx.buffertofile
 
call() - Method in interface com.github.davidmoten.rx.Checked.A0
 
call(T) - Method in interface com.github.davidmoten.rx.Checked.A1
 
call(T, R) - Method in interface com.github.davidmoten.rx.Checked.A2
 
call() - Method in interface com.github.davidmoten.rx.Checked.F0
 
call(T) - Method in interface com.github.davidmoten.rx.Checked.F1
 
call(T, R) - Method in interface com.github.davidmoten.rx.Checked.F2
 
call(Subscriber<? super T>) - Method in class com.github.davidmoten.rx.internal.operators.OnSubscribeCacheResetable
 
call(Subscriber<? super T>) - Method in class com.github.davidmoten.rx.internal.operators.OnSubscribeDoOnEmpty
 
call(Subscriber<? super T>) - Method in class com.github.davidmoten.rx.internal.operators.OnSubscribeMapLast
 
call(Subscriber<? super T>) - Method in class com.github.davidmoten.rx.internal.operators.OnSubscribeRepeating
 
call(Observable<T>) - Method in class com.github.davidmoten.rx.internal.operators.OperatorBufferPredicateBoundary
 
call(Subscriber<? super T>) - Method in class com.github.davidmoten.rx.internal.operators.OperatorBufferToFile
 
call(Subscriber<? super T>) - Method in class com.github.davidmoten.rx.internal.operators.OperatorDoOnNth
 
call(Subscriber<? super R>) - Method in class com.github.davidmoten.rx.internal.operators.OperatorFromTransformer
 
call(Subscriber<? super T>) - Method in class com.github.davidmoten.rx.internal.operators.OperatorSampleFirst
 
call(Subscriber<? super T>) - Method in class com.github.davidmoten.rx.internal.operators.OperatorUnsubscribeEagerly
 
call(Subscriber<? super T>) - Method in class com.github.davidmoten.rx.internal.operators.OperatorWindowMinMax
 
call(Subscriber<? super T>) - Method in class com.github.davidmoten.rx.internal.operators.OrderedMerge
 
call(Observable<T>) - Method in class com.github.davidmoten.rx.internal.operators.TransformerDelayFinalUnsubscribe
 
call(Observable<T>) - Method in class com.github.davidmoten.rx.internal.operators.TransformerLimitSubscribers
 
call(Observable<T>) - Method in class com.github.davidmoten.rx.internal.operators.TransformerOnBackpressureBufferRequestLimiting
 
call(Observable<T>) - Method in class com.github.davidmoten.rx.internal.operators.TransformerOnTerminateResume
 
call(Observable<In>) - Method in class com.github.davidmoten.rx.internal.operators.TransformerStateMachine
 
call(State, Subscriber<Out>) - Method in interface com.github.davidmoten.rx.StateMachine.Completion
 
call(State, In, Subscriber<Out>) - Method in interface com.github.davidmoten.rx.StateMachine.Transition
 
call(Observable<T>) - Method in class com.github.davidmoten.rx.util.MapWithIndex
 
checkArgument(boolean, String) - Static method in class com.github.davidmoten.util.Preconditions
 
Checked - Class in com.github.davidmoten.rx
Utility functions that are useful for brevity when using checked exceptions in lambdas with RxJava.
Checked() - Constructor for class com.github.davidmoten.rx.Checked
 
Checked.A0 - Interface in com.github.davidmoten.rx
 
Checked.A1<T> - Interface in com.github.davidmoten.rx
 
Checked.A2<T,R> - Interface in com.github.davidmoten.rx
 
Checked.F0<T> - Interface in com.github.davidmoten.rx
 
Checked.F1<T,R> - Interface in com.github.davidmoten.rx
 
Checked.F2<T,R,S> - Interface in com.github.davidmoten.rx
 
checkNotNull(Object) - Static method in class com.github.davidmoten.util.Preconditions
 
checkNotNull(Object, String) - Static method in class com.github.davidmoten.util.Preconditions
 
clear() - Method in class com.github.davidmoten.rx.internal.operators.FileBasedSPSCQueueMemoryMapped
 
close() - Static method in class com.github.davidmoten.rx.Actions
 
close() - Method in class com.github.davidmoten.rx.CloseableObservableWithReset
 
close() - Method in class com.github.davidmoten.rx.internal.operators.FileBasedSPSCQueueMemoryMappedReaderWriter
 
close() - Method in class com.github.davidmoten.util.ByteArrayOutputStreamNoCopyUnsynchronized
Closing a ByteArrayOutputStream has no effect.
CloseableObservableWithReset<T> - Class in com.github.davidmoten.rx
 
CloseableObservableWithReset(Observable<T>, Action0, Action0) - Constructor for class com.github.davidmoten.rx.CloseableObservableWithReset
 
closeableResourceFactory(Func0<T>) - Static method in class com.github.davidmoten.rx.ResourceManager
 
closeForRead() - Method in class com.github.davidmoten.rx.internal.operators.FileBasedSPSCQueueMemoryMappedReaderWriter
 
closeForWrite() - Method in class com.github.davidmoten.rx.internal.operators.FileBasedSPSCQueueMemoryMappedReaderWriter
 
collect() - Static method in class com.github.davidmoten.rx.Bytes
 
collectStats() - Static method in class com.github.davidmoten.rx.Functions
 
collectStats() - Static method in class com.github.davidmoten.rx.Transformers
 
collectStats(Func1<? super T, ? extends R>) - Static method in class com.github.davidmoten.rx.Transformers
 
collectWhile(Func0<R>, Action2<? super R, ? super T>, Func2<? super R, ? super T, Boolean>, Func1<? super R, Boolean>) - Static method in class com.github.davidmoten.rx.Transformers
Returns a Observable.Transformer that returns an Observable that is collected into Collection instances created by factory that are emitted when the collection and latest emission do not satisfy condition or on completion.
collectWhile(Func0<R>, Action2<? super R, ? super T>) - Static method in class com.github.davidmoten.rx.Transformers
Returns a Observable.Transformer that returns an Observable that is collected into Collection instances created by factory that are emitted when items are not equal or on completion.
collectWhile(Func0<R>, Action2<? super R, ? super T>, Func2<? super R, ? super T, Boolean>) - Static method in class com.github.davidmoten.rx.Transformers
 
com.github.davidmoten.rx - package com.github.davidmoten.rx
 
com.github.davidmoten.rx.buffertofile - package com.github.davidmoten.rx.buffertofile
 
com.github.davidmoten.rx.exceptions - package com.github.davidmoten.rx.exceptions
 
com.github.davidmoten.rx.internal.operators - package com.github.davidmoten.rx.internal.operators
 
com.github.davidmoten.rx.observables - package com.github.davidmoten.rx.observables
 
com.github.davidmoten.rx.subjects - package com.github.davidmoten.rx.subjects
 
com.github.davidmoten.rx.testing - package com.github.davidmoten.rx.testing
 
com.github.davidmoten.rx.util - package com.github.davidmoten.rx.util
 
com.github.davidmoten.util - package com.github.davidmoten.util
 
command() - Method in class com.github.davidmoten.rx.Processes.Parameters
 
completion(StateMachine.Completion<State, Out>) - Method in class com.github.davidmoten.rx.StateMachine.Builder3
 
computation(String) - Static method in class com.github.davidmoten.rx.Schedulers
 
computation() - Static method in class com.github.davidmoten.rx.Schedulers
 
concat(Observable<String>) - Static method in class com.github.davidmoten.rx.Strings
 
concat(Observable<String>, String) - Static method in class com.github.davidmoten.rx.Strings
 
constant(R) - Static method in class com.github.davidmoten.rx.Functions
 
constant0(T) - Static method in class com.github.davidmoten.rx.Functions
 
contains(Object) - Method in class com.github.davidmoten.rx.internal.operators.FileBasedSPSCQueueMemoryMapped
 
containsAll(Collection<?>) - Method in class com.github.davidmoten.rx.internal.operators.FileBasedSPSCQueueMemoryMapped
 
count() - Method in class com.github.davidmoten.rx.Statistics
 
count - Variable in class com.github.davidmoten.util.ByteArrayOutputStreamNoCopyUnsynchronized
The number of valid bytes in the buffer.
countDown(CountDownLatch) - Static method in class com.github.davidmoten.rx.Actions
 
countDown1(CountDownLatch) - Static method in class com.github.davidmoten.rx.Actions
 
create(Func0<? extends ServerSocket>, int, int, Action0, int, Func1<? super Socket, Boolean>) - Static method in class com.github.davidmoten.rx.internal.operators.ObservableServerSocket
 
create(Action1<? super T>, int) - Static method in class com.github.davidmoten.rx.internal.operators.OperatorDoOnNth
 
create(Collection<Observable<U>>) - Static method in class com.github.davidmoten.rx.internal.operators.OrderedMerge
 
create(Collection<Observable<U>>, Comparator<? super U>) - Static method in class com.github.davidmoten.rx.internal.operators.OrderedMerge
 
create(Collection<Observable<U>>, boolean) - Static method in class com.github.davidmoten.rx.internal.operators.OrderedMerge
 
create(Collection<Observable<U>>, Comparator<? super U>, boolean) - Static method in class com.github.davidmoten.rx.internal.operators.OrderedMerge
 
create(Func0<? extends State>, Func3<? super State, ? super In, ? super Subscriber<Out>, ? extends State>, Func2<? super State, ? super Subscriber<Out>, Boolean>, BackpressureStrategy, int) - Static method in class com.github.davidmoten.rx.internal.operators.TransformerStateMachine
 
create() - Method in class com.github.davidmoten.rx.IO.ServerSocketBuilder
 
create(Collection<Observable<T>>) - Static method in class com.github.davidmoten.rx.Obs
 
create(Collection<Observable<T>>, Comparator<? super T>) - Static method in class com.github.davidmoten.rx.Obs
 
create(Collection<Observable<T>>, boolean) - Static method in class com.github.davidmoten.rx.Obs
 
create(Collection<Observable<T>>, Comparator<? super T>, boolean) - Static method in class com.github.davidmoten.rx.Obs
 
create() - Method in class com.github.davidmoten.rx.ResourceManager.CloseableResourceManagerBuilder
 
create(Func0<T>, Action1<? super T>) - Static method in class com.github.davidmoten.rx.ResourceManager
 
create(Callable<T>, Action1<? super T>) - Static method in class com.github.davidmoten.rx.ResourceManager
 
create(Callable<T>, Checked.A1<? super T>) - Static method in class com.github.davidmoten.rx.ResourceManager
 
create(Func0<T>) - Static method in class com.github.davidmoten.rx.ResourceManager
 
create(Callable<T>) - Static method in class com.github.davidmoten.rx.ResourceManager
 
create() - Static method in class com.github.davidmoten.rx.Statistics
 
create() - Static method in class com.github.davidmoten.rx.subjects.PublishSubjectSingleSubscriber
Returns a new instance of a PublishSubjectSingleSubscriber.
create(T, S) - Static method in class com.github.davidmoten.rx.util.Pair
 
createWithRequest(long) - Static method in class com.github.davidmoten.rx.testing.TestSubscriber2
 
createWorker() - Method in class com.github.davidmoten.rx.SchedulerWithId
 

D

DataSerializer<T> - Interface in com.github.davidmoten.rx.buffertofile
 
DataSerializers - Class in com.github.davidmoten.rx.buffertofile
 
decode(CharsetDecoder) - Static method in class com.github.davidmoten.rx.internal.operators.TransformerDecode
 
decode(Observable<byte[]>, CharsetDecoder) - Static method in class com.github.davidmoten.rx.Strings
 
decode(Observable<byte[]>, Charset) - Static method in class com.github.davidmoten.rx.Strings
 
decode(Observable<byte[]>, String) - Static method in class com.github.davidmoten.rx.Strings
 
decode(CharsetDecoder) - Static method in class com.github.davidmoten.rx.Transformers
Decodes a stream of multibyte chunks into a stream of strings that works on infinite streams and handles when a multibyte character spans two chunks.
decrement0(AtomicInteger) - Static method in class com.github.davidmoten.rx.Actions
 
decrement1(AtomicInteger) - Static method in class com.github.davidmoten.rx.Actions
 
DEFAULT_FILE_PREFIX - Static variable in class com.github.davidmoten.rx.buffertofile.Options
 
defaultInstance() - Static method in class com.github.davidmoten.rx.buffertofile.Options
 
delay(Long, TimeUnit) - Method in class com.github.davidmoten.rx.RetryWhen.Builder
 
delay(long, TimeUnit) - Static method in class com.github.davidmoten.rx.RetryWhen
 
delay(Func1<? super T, Long>, Func0<Double>, long, Scheduler) - Static method in class com.github.davidmoten.rx.Transformers
 
delayError(boolean) - Method in class com.github.davidmoten.rx.buffertofile.Options.Builder
Sets if errors are delayed or not when detected.
delayError() - Method in class com.github.davidmoten.rx.buffertofile.Options
 
delayError(boolean) - Static method in class com.github.davidmoten.rx.buffertofile.Options
 
delayFinalUnsubscribe(long, TimeUnit) - Static method in class com.github.davidmoten.rx.Transformers
If multiple concurrently open subscriptions happen to a source transformed by this method then an additional do-nothing subscription will be maintained to the source and will only be closed after the specified duration has passed from the final unsubscription of the open subscriptions.
delayFinalUnsubscribe(long, TimeUnit, Scheduler) - Static method in class com.github.davidmoten.rx.Transformers
If multiple concurrently open subscriptions happen to a source transformed by this method then an additional do-nothing subscription will be maintained to the source and will only be closed after the specified duration has passed from the final unsubscription of the open subscriptions.
delays(Observable<Long>, TimeUnit) - Method in class com.github.davidmoten.rx.RetryWhen.Builder
 
delays(Observable<Long>, TimeUnit) - Static method in class com.github.davidmoten.rx.RetryWhen
 
delaysInt(Observable<Integer>, TimeUnit) - Method in class com.github.davidmoten.rx.RetryWhen.Builder
 
delaysInt(Observable<Integer>, TimeUnit) - Static method in class com.github.davidmoten.rx.RetryWhen
 
DeliveredMoreThanRequestedException() - Constructor for exception com.github.davidmoten.rx.testing.TestingHelper.DeliveredMoreThanRequestedException
 
deserialize(DataInput) - Method in interface com.github.davidmoten.rx.buffertofile.DataSerializer
Deserializes the bytes pointed by input.
directory() - Method in class com.github.davidmoten.rx.Processes.Parameters
 
disableRollover() - Method in class com.github.davidmoten.rx.buffertofile.Options.Builder
 
disableRollover() - Static method in class com.github.davidmoten.rx.buffertofile.Options
 
disposeAction(Action1<? super T>) - Method in class com.github.davidmoten.rx.ResourceManager.ResourceManagerBuilder
 
disposeEagerly(boolean) - Method in class com.github.davidmoten.rx.ResourceManager.CloseableResourceManagerBuilder
 
disposeEagerly(boolean) - Method in class com.github.davidmoten.rx.ResourceManager.ResourceManagerBuilder
 
doNothing0() - Static method in class com.github.davidmoten.rx.Actions
 
doNothing1() - Static method in class com.github.davidmoten.rx.Actions
 
doNothing2() - Static method in class com.github.davidmoten.rx.Actions
 
doNothing3() - Static method in class com.github.davidmoten.rx.Actions
 
doOnEmpty(Action0) - Static method in class com.github.davidmoten.rx.Transformers
Modifies the source Observable so that it invokes an action when it calls onCompleted and no items were emitted.
doOnFirst(Action1<? super T>) - Static method in class com.github.davidmoten.rx.Transformers
Returns a Observable.Transformer that applied to a source Observable calls the given action on the first onNext emission.
doOnNext(int, Action1<? super T>) - Static method in class com.github.davidmoten.rx.Transformers
Returns a Observable.Transformer that applied to a source Observable calls the given action on the nth onNext emission.
DownstreamUnsubscriptionDidNotOccurException() - Constructor for exception com.github.davidmoten.rx.testing.TestingHelper.DownstreamUnsubscriptionDidNotOccurException
 
durationMs() - Method in class com.github.davidmoten.rx.RetryWhen.ErrorAndDuration
 

E

element() - Method in class com.github.davidmoten.rx.internal.operators.FileBasedSPSCQueueMemoryMapped
 
env() - Method in class com.github.davidmoten.rx.Processes.Parameters
 
ErrorAndDuration(Throwable, long) - Constructor for class com.github.davidmoten.rx.RetryWhen.ErrorAndDuration
 
execute(String...) - Static method in class com.github.davidmoten.rx.Processes
 
execute(Processes.Parameters) - Static method in class com.github.davidmoten.rx.Processes
 
exitCode() - Method in exception com.github.davidmoten.rx.Processes.ProcessException
 
expect(R...) - Method in class com.github.davidmoten.rx.testing.TestingHelper.CaseBuilder
 
expect(List<R>) - Method in class com.github.davidmoten.rx.testing.TestingHelper.CaseBuilder
 
expectAnyOrder(R...) - Method in class com.github.davidmoten.rx.testing.TestingHelper.CaseBuilder
 
ExpectedErrorNotReceivedException() - Constructor for exception com.github.davidmoten.rx.testing.TestingHelper.ExpectedErrorNotReceivedException
 
ExpectedExceptionNotThrownException() - Constructor for exception com.github.davidmoten.rx.testing.TestingHelper.ExpectedExceptionNotThrownException
 
expectEmpty() - Method in class com.github.davidmoten.rx.testing.TestingHelper.CaseBuilder
 
expectError() - Method in class com.github.davidmoten.rx.testing.TestingHelper.CaseBuilder
 
expectError(Class<? extends Throwable>) - Method in class com.github.davidmoten.rx.testing.TestingHelper.CaseBuilder
 
expectException(Class<? extends RuntimeException>) - Method in class com.github.davidmoten.rx.testing.TestingHelper.CaseBuilder
 
expectSize(long) - Method in class com.github.davidmoten.rx.testing.TestingHelper.CaseBuilder
 
exponentialBackoff(long, TimeUnit, double) - Method in class com.github.davidmoten.rx.RetryWhen.Builder
 
exponentialBackoff(long, TimeUnit) - Method in class com.github.davidmoten.rx.RetryWhen.Builder
 
exponentialBackoff(long, TimeUnit, double) - Static method in class com.github.davidmoten.rx.RetryWhen
 
exponentialBackoff(long, TimeUnit) - Static method in class com.github.davidmoten.rx.RetryWhen
 

F

f0(Checked.F0<T>) - Static method in class com.github.davidmoten.rx.Checked
Returns a Func0 that reports any exception thrown by f wrapped by a RuntimeException.
f1(Checked.F1<T, R>) - Static method in class com.github.davidmoten.rx.Checked
 
f2(Checked.F2<T, R, S>) - Static method in class com.github.davidmoten.rx.Checked
 
failWhenInstanceOf(Class<? extends Throwable>...) - Method in class com.github.davidmoten.rx.RetryWhen.Builder
 
failWhenInstanceOf(Class<? extends Throwable>...) - Static method in class com.github.davidmoten.rx.RetryWhen
 
FileBasedSPSCQueueMemoryMapped<T> - Class in com.github.davidmoten.rx.internal.operators
 
FileBasedSPSCQueueMemoryMapped(Func0<File>, int, DataSerializer<T>) - Constructor for class com.github.davidmoten.rx.internal.operators.FileBasedSPSCQueueMemoryMapped
 
FileBasedSPSCQueueMemoryMappedReaderWriter<T> - Class in com.github.davidmoten.rx.internal.operators
 
FileBasedSPSCQueueMemoryMappedReaderWriter(File, int, DataSerializer<T>) - Constructor for class com.github.davidmoten.rx.internal.operators.FileBasedSPSCQueueMemoryMappedReaderWriter
 
fileFactory(Func0<File>) - Method in class com.github.davidmoten.rx.buffertofile.Options.Builder
Sets the file factory to be used by the queue storage mechanism.
fileFactory() - Method in class com.github.davidmoten.rx.buffertofile.Options
 
fileFactory(Func0<File>) - Static method in class com.github.davidmoten.rx.buffertofile.Options
 
from(InputStream, int) - Static method in class com.github.davidmoten.rx.Bytes
Returns an Observable stream of byte arrays from the given InputStream between 1 and size bytes.
from(File) - Static method in class com.github.davidmoten.rx.Bytes
 
from(File, int) - Static method in class com.github.davidmoten.rx.Bytes
 
from(InputStream) - Static method in class com.github.davidmoten.rx.Bytes
Returns an Observable stream of byte arrays from the given InputStream of 8192 bytes.
from(Reader, int) - Static method in class com.github.davidmoten.rx.Strings
 
from(Reader) - Static method in class com.github.davidmoten.rx.Strings
 
from(InputStream) - Static method in class com.github.davidmoten.rx.Strings
 
from(InputStream, Charset) - Static method in class com.github.davidmoten.rx.Strings
 
from(InputStream, Charset, int) - Static method in class com.github.davidmoten.rx.Strings
 
from(File) - Static method in class com.github.davidmoten.rx.Strings
 
from(File, Charset) - Static method in class com.github.davidmoten.rx.Strings
 
from(Func0<Reader>) - Static method in class com.github.davidmoten.rx.Strings
 
from(T...) - Method in class com.github.davidmoten.rx.testing.TestingHelper.CaseBuilder
 
from(Observable<T>) - Method in class com.github.davidmoten.rx.testing.TestingHelper.CaseBuilder
 
fromClasspath(String, Charset) - Static method in class com.github.davidmoten.rx.Strings
 
fromClasspath(String) - Static method in class com.github.davidmoten.rx.Strings
 
fromEmpty() - Method in class com.github.davidmoten.rx.testing.TestingHelper.CaseBuilder
 
fromError() - Method in class com.github.davidmoten.rx.testing.TestingHelper.CaseBuilder
 
fromErrorAfter(T...) - Method in class com.github.davidmoten.rx.testing.TestingHelper.CaseBuilder
 
fromErrorAfter(Observable<T>) - Method in class com.github.davidmoten.rx.testing.TestingHelper.CaseBuilder
 
fromNullable(T) - Static method in class com.github.davidmoten.util.Optional
 
fromQueue(Queue<T>) - Static method in class com.github.davidmoten.rx.Obs
 
function(Func1<Observable<T>, Observable<R>>) - Method in class com.github.davidmoten.rx.testing.TestingHelper.Builder
Sets transformation to be tested and returns the current builder.
function(Func1<Observable<T>, Observable<R>>) - Static method in class com.github.davidmoten.rx.testing.TestingHelper
Sets the transformation to be tested and returns a builder to create test cases.
Functions - Class in com.github.davidmoten.rx
 

G

generateState() - Method in class com.github.davidmoten.rx.internal.operators.OnSubscribeFromQueue
 
generateState() - Method in class com.github.davidmoten.rx.internal.operators.OnSubscribeInputStream
 
generateState() - Method in class com.github.davidmoten.rx.internal.operators.OnSubscribeReader
 
get() - Method in class com.github.davidmoten.util.Optional
 
getAndAddRequest(AtomicLongFieldUpdater<T>, T, long) - Static method in class com.github.davidmoten.rx.util.BackpressureUtils
Adds n to requested field and returns the value prior to addition once the addition is successful (uses CAS semantics).
getAndAddRequest(AtomicLong, long) - Static method in class com.github.davidmoten.rx.util.BackpressureUtils
Adds n to requested and returns the value prior to addition once the addition is successful (uses CAS semantics).
getComment() - Method in class com.github.davidmoten.rx.util.ZippedEntry
 
getCompletions() - Method in class com.github.davidmoten.rx.testing.TestSubscriber2
 
getCompressedSize() - Method in class com.github.davidmoten.rx.util.ZippedEntry
 
getCrc() - Method in class com.github.davidmoten.rx.util.ZippedEntry
 
getExtra() - Method in class com.github.davidmoten.rx.util.ZippedEntry
 
getInputStream() - Method in class com.github.davidmoten.rx.util.ZippedEntry
 
getLastSeenThread() - Method in class com.github.davidmoten.rx.testing.TestSubscriber2
 
getMethod() - Method in class com.github.davidmoten.rx.util.ZippedEntry
 
getName() - Method in class com.github.davidmoten.rx.util.ZippedEntry
 
getOnErrorEvents() - Method in class com.github.davidmoten.rx.testing.TestSubscriber2
 
getOnNextEvents() - Method in class com.github.davidmoten.rx.testing.TestSubscriber2
 
getSize() - Method in class com.github.davidmoten.rx.util.ZippedEntry
 
getTime() - Method in class com.github.davidmoten.rx.util.ZippedEntry
 
getValueCount() - Method in class com.github.davidmoten.rx.testing.TestSubscriber2
 
groupByEvicting(Func1<? super T, ? extends K>, Func1<? super T, ? extends R>, Func1<Action1<K>, Map<K, Object>>) - Static method in class com.github.davidmoten.rx.Transformers
Groups the items emitted by an Observable according to a specified criterion, and emits these grouped items as GroupedObservables.

H

hasObservers() - Method in class com.github.davidmoten.rx.subjects.PublishSubjectSingleSubscriber
 

I

identity() - Static method in class com.github.davidmoten.rx.Functions
 
Ignore - Class in com.github.davidmoten.rx
 
ignoreElementsThen(Observable<R>) - Static method in class com.github.davidmoten.rx.Transformers
Returns an observable that subscribes to this and wait for completion but doesn't emit any items and once completes emits the next observable.
increment0(AtomicInteger) - Static method in class com.github.davidmoten.rx.Actions
 
increment1(AtomicInteger) - Static method in class com.github.davidmoten.rx.Actions
 
index() - Method in class com.github.davidmoten.rx.util.MapWithIndex.Indexed
 
Indexed(T, long) - Constructor for class com.github.davidmoten.rx.util.MapWithIndex.Indexed
 
initialRequest(int) - Method in class com.github.davidmoten.rx.StateMachine.Builder3
 
initialState(State) - Method in class com.github.davidmoten.rx.StateMachine.Builder
 
initialStateFactory(Func0<State>) - Method in class com.github.davidmoten.rx.StateMachine.Builder
 
instance() - Static method in class com.github.davidmoten.rx.internal.operators.NullSentinel
 
instance() - Static method in class com.github.davidmoten.rx.internal.operators.OperatorUnsubscribeEagerly
 
instance() - Static method in class com.github.davidmoten.rx.internal.operators.TransformerOnBackpressureBufferRequestLimiting
 
instance() - Static method in class com.github.davidmoten.rx.util.MapWithIndex
 
integer() - Static method in class com.github.davidmoten.rx.buffertofile.DataSerializers
 
intervalLong(long, TimeUnit, Scheduler) - Static method in class com.github.davidmoten.rx.Obs
 
intervalLong(long, TimeUnit) - Static method in class com.github.davidmoten.rx.Obs
 
IO - Class in com.github.davidmoten.rx
 
IO.ServerSocketBuilder - Class in com.github.davidmoten.rx
 
IORuntimeException - Exception in com.github.davidmoten.rx.exceptions
 
IORuntimeException(IOException) - Constructor for exception com.github.davidmoten.rx.exceptions.IORuntimeException
 
isEmpty() - Method in class com.github.davidmoten.rx.internal.operators.FileBasedSPSCQueueMemoryMapped
 
isNotNull() - Static method in class com.github.davidmoten.rx.Functions
 
isNull() - Static method in class com.github.davidmoten.rx.Functions
 
isNullSentinel(Object) - Static method in class com.github.davidmoten.rx.internal.operators.NullSentinel
 
isPresent() - Method in class com.github.davidmoten.util.Optional
 
isUnsubscribed() - Method in class com.github.davidmoten.rx.internal.operators.FileBasedSPSCQueueMemoryMapped
 
iterable(List<T>) - Static method in class com.github.davidmoten.rx.internal.operators.Permutations
 
iterator() - Method in class com.github.davidmoten.rx.internal.operators.FileBasedSPSCQueueMemoryMapped
 
iterator(List<T>) - Static method in class com.github.davidmoten.rx.internal.operators.Permutations
 

J

javaIO() - Static method in class com.github.davidmoten.rx.buffertofile.DataSerializers
 
Jaxws - Class in com.github.davidmoten.rx
 
Jaxws() - Constructor for class com.github.davidmoten.rx.Jaxws
 
Jaxws.ObservableAdapter - Class in com.github.davidmoten.rx
 
join(Observable<String>) - Static method in class com.github.davidmoten.rx.Strings
 
join(Observable<String>, String) - Static method in class com.github.davidmoten.rx.Strings
 
just() - Static method in class com.github.davidmoten.rx.Functions
 

K

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

L

left() - Method in class com.github.davidmoten.rx.internal.operators.Permutations.Swap
 
left() - Method in class com.github.davidmoten.rx.util.Pair
 
limitSubscribers(AtomicInteger, int) - Static method in class com.github.davidmoten.rx.Transformers
 
limitSubscribers(int) - Static method in class com.github.davidmoten.rx.Transformers
 

M

main(String[]) - Static method in class com.github.davidmoten.rx.internal.operators.TransformerOnBackpressureBufferRequestLimiting
 
main(String[]) - Static method in class com.github.davidmoten.rx.Processes
 
main(String[]) - Static method in class com.github.davidmoten.rx.Schedulers
 
map(Checked.F1<? super T, ? extends R>, Checked.A1<? super R>) - Method in class com.github.davidmoten.rx.ResourceManager
 
map(Func1<? super T, ? extends R>, Action1<? super R>) - Method in class com.github.davidmoten.rx.ResourceManager
 
map(Func1<? super T, ? extends R>) - Method in class com.github.davidmoten.rx.ResourceManager
 
mapLast(Func1<? super T, ? extends T>) - Static method in class com.github.davidmoten.rx.Transformers
 
mapWithIndex() - Static method in class com.github.davidmoten.rx.Transformers
Returns a Observable.Transformer that wraps stream emissions with their corresponding zero based index numbers (0,1,2,3,..) in instances of MapWithIndex.Indexed.
MapWithIndex<T> - Class in com.github.davidmoten.rx.util
 
MapWithIndex() - Constructor for class com.github.davidmoten.rx.util.MapWithIndex
 
MapWithIndex.Indexed<T> - Class in com.github.davidmoten.rx.util
 
marshal(Observable) - Method in class com.github.davidmoten.rx.Jaxws.ObservableAdapter
 
Maths - Class in com.github.davidmoten.rx
 
maxRetries(int) - Method in class com.github.davidmoten.rx.RetryWhen.Builder
 
maxRetries(int) - Static method in class com.github.davidmoten.rx.RetryWhen
 
mean() - Method in class com.github.davidmoten.rx.Statistics
 
Multiplier<T> - Interface in com.github.davidmoten.rx
A convenient shorthand way of specifying a Func1 used in a flatMap for instance.

N

name(String) - Method in class com.github.davidmoten.rx.testing.TestingHelper.Builder
Sets the name of the test which is used in the name of a junit test.
name(String) - Method in class com.github.davidmoten.rx.testing.TestingHelper.CaseBuilder
 
next(Queue<T>, Observer<? super T>) - Method in class com.github.davidmoten.rx.internal.operators.OnSubscribeFromQueue
 
next(InputStream, Observer<? super byte[]>) - Method in class com.github.davidmoten.rx.internal.operators.OnSubscribeInputStream
 
next(Reader, Observer<? super String>) - Method in class com.github.davidmoten.rx.internal.operators.OnSubscribeReader
 
not(Func1<T, Boolean>) - Static method in class com.github.davidmoten.rx.Functions
 
NotPresentException() - Constructor for exception com.github.davidmoten.util.Optional.NotPresentException
 
NullSentinel - Class in com.github.davidmoten.rx.internal.operators
 

O

Obs - Class in com.github.davidmoten.rx
 
Obs() - Constructor for class com.github.davidmoten.rx.Obs
 
observable() - Method in class com.github.davidmoten.rx.CloseableObservableWithReset
 
observable(Func1<? super T, ? extends Observable<? extends R>>) - Method in class com.github.davidmoten.rx.ResourceManager
 
ObservableAdapter() - Constructor for class com.github.davidmoten.rx.Jaxws.ObservableAdapter
 
ObservableServerSocket - Class in com.github.davidmoten.rx.internal.operators
 
of(T) - Static method in class com.github.davidmoten.util.Optional
 
offer(T) - Method in class com.github.davidmoten.rx.internal.operators.FileBasedSPSCQueueMemoryMapped
 
offer(T) - Method in class com.github.davidmoten.rx.internal.operators.FileBasedSPSCQueueMemoryMappedReaderWriter
Returns true if value written to file or false if not enough space (writes and end-of-file marker in the fixed-length memory mapped file).
onBackpressureBufferRequestLimiting() - Static method in class com.github.davidmoten.rx.Transformers
Rather than requesting Long.MAX_VALUE of upstream as does `Observable.onBackpressureBuffer`, this variant only requests of upstream what is requested of it.
onBackpressureBufferToFile() - Static method in class com.github.davidmoten.rx.Transformers
 
onBackpressureBufferToFile(DataSerializer<T>) - Static method in class com.github.davidmoten.rx.Transformers
 
onBackpressureBufferToFile(DataSerializer<T>, Scheduler) - Static method in class com.github.davidmoten.rx.Transformers
 
onBackpressureBufferToFile(DataSerializer<T>, Scheduler, Options) - Static method in class com.github.davidmoten.rx.Transformers
 
onCompleted() - Method in class com.github.davidmoten.rx.subjects.PublishSubjectSingleSubscriber
 
onCompleted() - Method in class com.github.davidmoten.rx.testing.TestSubscriber2
 
onError(Throwable) - Method in class com.github.davidmoten.rx.subjects.PublishSubjectSingleSubscriber
 
onError(Throwable) - Method in class com.github.davidmoten.rx.testing.TestSubscriber2
 
onNext(T) - Method in class com.github.davidmoten.rx.subjects.PublishSubjectSingleSubscriber
 
onNext(T) - Method in class com.github.davidmoten.rx.testing.TestSubscriber2
 
onStart() - Method in class com.github.davidmoten.rx.testing.TestSubscriber2
 
OnSubscribeCacheResetable<T> - Class in com.github.davidmoten.rx.internal.operators
 
OnSubscribeCacheResetable(Observable<T>) - Constructor for class com.github.davidmoten.rx.internal.operators.OnSubscribeCacheResetable
 
OnSubscribeDoOnEmpty<T> - Class in com.github.davidmoten.rx.internal.operators
 
OnSubscribeDoOnEmpty(Observable<T>, Action0) - Constructor for class com.github.davidmoten.rx.internal.operators.OnSubscribeDoOnEmpty
 
OnSubscribeFromQueue<T> - Class in com.github.davidmoten.rx.internal.operators
 
OnSubscribeFromQueue(Queue<T>) - Constructor for class com.github.davidmoten.rx.internal.operators.OnSubscribeFromQueue
 
OnSubscribeInputStream - Class in com.github.davidmoten.rx.internal.operators
 
OnSubscribeInputStream(InputStream, int) - Constructor for class com.github.davidmoten.rx.internal.operators.OnSubscribeInputStream
 
OnSubscribeMapLast<T> - Class in com.github.davidmoten.rx.internal.operators
 
OnSubscribeMapLast(Observable<T>, Func1<? super T, ? extends T>) - Constructor for class com.github.davidmoten.rx.internal.operators.OnSubscribeMapLast
 
OnSubscribeReader - Class in com.github.davidmoten.rx.internal.operators
 
OnSubscribeReader(Reader, int) - Constructor for class com.github.davidmoten.rx.internal.operators.OnSubscribeReader
 
OnSubscribeRepeating<T> - Class in com.github.davidmoten.rx.internal.operators
 
OnSubscribeRepeating(T) - Constructor for class com.github.davidmoten.rx.internal.operators.OnSubscribeRepeating
 
onTerminateResume(Func1<Throwable, Observable<T>>, Observable<T>) - Static method in class com.github.davidmoten.rx.Transformers
 
openForRead() - Method in class com.github.davidmoten.rx.internal.operators.FileBasedSPSCQueueMemoryMappedReaderWriter
 
openForWrite() - Method in class com.github.davidmoten.rx.internal.operators.FileBasedSPSCQueueMemoryMappedReaderWriter
 
OperatorBufferPredicateBoundary<T> - Class in com.github.davidmoten.rx.internal.operators
Buffers values into a continuous, non-overlapping Lists where the boundary is determined by a predicate returning true.
OperatorBufferPredicateBoundary(Func1<? super T, Boolean>, int, int, boolean) - Constructor for class com.github.davidmoten.rx.internal.operators.OperatorBufferPredicateBoundary
 
OperatorBufferToFile<T> - Class in com.github.davidmoten.rx.internal.operators
 
OperatorBufferToFile(DataSerializer<T>, Scheduler, Options) - Constructor for class com.github.davidmoten.rx.internal.operators.OperatorBufferToFile
 
OperatorDoOnNth<T> - Class in com.github.davidmoten.rx.internal.operators
 
OperatorFromTransformer<R,T> - Class in com.github.davidmoten.rx.internal.operators
Converts an Transformer (a function converting one Observable into another) into an Observable.Operator.
OperatorFromTransformer(Func1<? super Observable<T>, ? extends Observable<R>>) - Constructor for class com.github.davidmoten.rx.internal.operators.OperatorFromTransformer
Constructor.
OperatorSampleFirst<T> - Class in com.github.davidmoten.rx.internal.operators
Throttle by windowing a stream and returning the first value in each window.
OperatorSampleFirst(long, TimeUnit, Scheduler) - Constructor for class com.github.davidmoten.rx.internal.operators.OperatorSampleFirst
 
OperatorUnsubscribeEagerly<T> - Class in com.github.davidmoten.rx.internal.operators
 
OperatorWindowMinMax<T> - Class in com.github.davidmoten.rx.internal.operators
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).
OperatorWindowMinMax(int, Comparator<? super T>, OperatorWindowMinMax.Metric) - Constructor for class com.github.davidmoten.rx.internal.operators.OperatorWindowMinMax
 
OperatorWindowMinMax.Metric - Enum in com.github.davidmoten.rx.internal.operators
 
Optional<T> - Class in com.github.davidmoten.util
 
Optional.NotPresentException - Exception in com.github.davidmoten.util
 
Options - Class in com.github.davidmoten.rx.buffertofile
 
Options.Builder - Class in com.github.davidmoten.rx.buffertofile
 
or(T) - Method in class com.github.davidmoten.util.Optional
 
OrderedMerge<T> - Class in com.github.davidmoten.rx.internal.operators
 
orderedMergeWith(Observable<T>, Comparator<? super T>) - Static method in class com.github.davidmoten.rx.Transformers
Returns the source Observable merged with the other observable using the given Comparator for order.
orderedMergeWith(Collection<Observable<T>>, Comparator<? super T>) - Static method in class com.github.davidmoten.rx.Transformers
Returns the source Observable merged with all of the other observables using the given Comparator for order.

P

Pair<T,S> - Class in com.github.davidmoten.rx.util
 
Pair(T, S) - Constructor for class com.github.davidmoten.rx.util.Pair
 
Parameters(List<String>, Optional<Map<String, String>>, boolean, File, Optional<Long>) - Constructor for class com.github.davidmoten.rx.Processes.Parameters
 
peek() - Method in class com.github.davidmoten.rx.internal.operators.FileBasedSPSCQueueMemoryMapped
 
perform(Action0) - Method in class com.github.davidmoten.rx.testing.TestSubscriber2
 
Permutations - Class in com.github.davidmoten.rx.internal.operators
 
permutations(int) - Static method in class com.github.davidmoten.rx.Obs
 
permutations(List<T>) - Static method in class com.github.davidmoten.rx.Obs
 
Permutations.Swap<T> - Class in com.github.davidmoten.rx.internal.operators
 
poll() - Method in class com.github.davidmoten.rx.internal.operators.FileBasedSPSCQueueMemoryMapped
 
poll() - Method in class com.github.davidmoten.rx.internal.operators.FileBasedSPSCQueueMemoryMappedReaderWriter
 
preAcceptAction(Action0) - Method in class com.github.davidmoten.rx.IO.ServerSocketBuilder
 
Preconditions - Class in com.github.davidmoten.util
 
Preconditions() - Constructor for class com.github.davidmoten.util.Preconditions
 
Predicate<T> - Interface in com.github.davidmoten.rx
A convenient sorthand way of specifying a Func1 used in a filter for instance.
primes() - Static method in class com.github.davidmoten.rx.Maths
 
println() - Static method in class com.github.davidmoten.rx.Actions
 
printStackTrace1() - Static method in class com.github.davidmoten.rx.Actions
 
process(byte[], ByteBuffer, boolean, CharsetDecoder, Subscriber<String>) - Static method in class com.github.davidmoten.rx.internal.operators.TransformerDecode
 
Processes - Class in com.github.davidmoten.rx
 
Processes() - Constructor for class com.github.davidmoten.rx.Processes
 
Processes.Parameters - Class in com.github.davidmoten.rx
 
Processes.ProcessException - Exception in com.github.davidmoten.rx
 
ProcessException(int) - Constructor for exception com.github.davidmoten.rx.Processes.ProcessException
 
PublishSubjectSingleSubscriber<T> - Class in com.github.davidmoten.rx.subjects
A Subject that supports a maximum of one Subscriber.

Q

QueueWithSubscription<T> - Interface in com.github.davidmoten.rx.internal.operators
 

R

read(Class<T>, File) - Method in class com.github.davidmoten.rx.Serialized.KryoBuilder
 
read(Class<T>, File, int) - Method in class com.github.davidmoten.rx.Serialized.KryoBuilder
 
read(Class<T>, Input, int) - Method in class com.github.davidmoten.rx.Serialized.KryoBuilder
 
read(ObjectInputStream) - Static method in class com.github.davidmoten.rx.Serialized
Returns the deserialized objects from the given InputStream as an Observable stream.
read(File, int) - Static method in class com.github.davidmoten.rx.Serialized
Returns the deserialized objects from the given File as an Observable stream.
read(File) - Static method in class com.github.davidmoten.rx.Serialized
Returns the deserialized objects from the given File as an Observable stream.
readTimeoutMs(int) - Method in class com.github.davidmoten.rx.IO.ServerSocketBuilder
 
remove(Object) - Method in class com.github.davidmoten.rx.internal.operators.FileBasedSPSCQueueMemoryMapped
 
remove() - Method in class com.github.davidmoten.rx.internal.operators.FileBasedSPSCQueueMemoryMapped
 
removeAll(Collection<?>) - Method in class com.github.davidmoten.rx.internal.operators.FileBasedSPSCQueueMemoryMapped
 
removePairs(Func1<? super T, Boolean>, Func2<? super T, ? super T, Boolean>) - Static method in class com.github.davidmoten.rx.Transformers
Removes pairs non-recursively from a stream.
repeating(T) - Static method in class com.github.davidmoten.rx.Obs
Returns an Observable that epeats emitting t without completing.
repeatLast() - Static method in class com.github.davidmoten.rx.Transformers
 
requestMore(long) - Method in class com.github.davidmoten.rx.testing.TestSubscriber2
 
reset() - Method in class com.github.davidmoten.rx.CloseableObservableWithReset
 
reset() - Method in class com.github.davidmoten.rx.internal.operators.OnSubscribeCacheResetable
 
reset() - Method in class com.github.davidmoten.rx.observables.CachedObservable
 
reset() - Method in class com.github.davidmoten.util.ByteArrayOutputStreamNoCopyUnsynchronized
Resets the count field of this byte array output stream to zero, so that all currently accumulated output in the output stream is discarded.
resourceFactory(Func0<T>) - Static method in class com.github.davidmoten.rx.ResourceManager
 
ResourceManager<T> - Class in com.github.davidmoten.rx
 
ResourceManager(Func0<T>, Action1<? super T>, boolean) - Constructor for class com.github.davidmoten.rx.ResourceManager
 
ResourceManager.CloseableResourceManagerBuilder<T extends Closeable> - Class in com.github.davidmoten.rx
 
ResourceManager.ResourceManagerBuilder<T> - Class in com.github.davidmoten.rx
 
retainAll(Collection<?>) - Method in class com.github.davidmoten.rx.internal.operators.FileBasedSPSCQueueMemoryMapped
 
retryIf(Func1<Throwable, Boolean>) - Method in class com.github.davidmoten.rx.RetryWhen.Builder
 
retryIf(Func1<Throwable, Boolean>) - Static method in class com.github.davidmoten.rx.RetryWhen
 
RetryWhen - Class in com.github.davidmoten.rx
Provides builder for the Func1 parameter of Observable.retryWhen(Func1).
RetryWhen() - Constructor for class com.github.davidmoten.rx.RetryWhen
 
RetryWhen.Builder - Class in com.github.davidmoten.rx
 
RetryWhen.ErrorAndDuration - Class in com.github.davidmoten.rx
 
retryWhenInstanceOf(Class<? extends Throwable>...) - Method in class com.github.davidmoten.rx.RetryWhen.Builder
 
retryWhenInstanceOf(Class<? extends Throwable>...) - Static method in class com.github.davidmoten.rx.RetryWhen
 
right() - Method in class com.github.davidmoten.rx.internal.operators.Permutations.Swap
 
right() - Method in class com.github.davidmoten.rx.util.Pair
 
rolloverEnabled() - Method in class com.github.davidmoten.rx.buffertofile.Options
 
rolloverEvery(long) - Method in class com.github.davidmoten.rx.buffertofile.Options.Builder
 
rolloverEvery() - Method in class com.github.davidmoten.rx.buffertofile.Options
 
rolloverEvery(long) - Static method in class com.github.davidmoten.rx.buffertofile.Options
 
rolloverSizeBytes(long) - Method in class com.github.davidmoten.rx.buffertofile.Options.Builder
 
rolloverSizeBytes() - Method in class com.github.davidmoten.rx.buffertofile.Options
 
rolloverSizeBytes(long) - Static method in class com.github.davidmoten.rx.buffertofile.Options
 
rolloverSizeMB(double) - Method in class com.github.davidmoten.rx.buffertofile.Options.Builder
 
rolloverSizeMB(double) - Static method in class com.github.davidmoten.rx.buffertofile.Options
 

S

sampleFirst(long, TimeUnit) - Static method in class com.github.davidmoten.rx.Transformers
 
sampleFirst(long, TimeUnit, Scheduler) - Static method in class com.github.davidmoten.rx.Transformers
 
scheduler(Scheduler) - Method in class com.github.davidmoten.rx.RetryWhen.Builder
 
scheduler(Scheduler) - Static method in class com.github.davidmoten.rx.RetryWhen
 
Schedulers - Class in com.github.davidmoten.rx
 
Schedulers() - Constructor for class com.github.davidmoten.rx.Schedulers
 
SchedulerWithId - Class in com.github.davidmoten.rx
 
SchedulerWithId(Scheduler, String) - Constructor for class com.github.davidmoten.rx.SchedulerWithId
 
sd() - Method in class com.github.davidmoten.rx.Statistics
 
serialize(DataOutput, T) - Method in interface com.github.davidmoten.rx.buffertofile.DataSerializer
Serializes an object to a data stream.
Serialized - Class in com.github.davidmoten.rx
Utility class for writing Observable streams to ObjectOutputStreams and reading Observable streams of indeterminate size from ObjectInputStreams.
Serialized() - Constructor for class com.github.davidmoten.rx.Serialized
 
Serialized.KryoBuilder - Class in com.github.davidmoten.rx
 
serverSocket(int) - Static method in class com.github.davidmoten.rx.IO
 
serverSocket(Func0<? extends ServerSocket>) - Static method in class com.github.davidmoten.rx.IO
 
serverSocketAutoAllocatePort(Action1<Integer>) - Static method in class com.github.davidmoten.rx.IO
 
ServerSocketBuilder(Func0<? extends ServerSocket>) - Constructor for class com.github.davidmoten.rx.IO.ServerSocketBuilder
 
setAtomic(AtomicInteger) - Static method in class com.github.davidmoten.rx.Actions
 
setAtomic(AtomicLong) - Static method in class com.github.davidmoten.rx.Actions
 
setAtomic(AtomicBoolean) - Static method in class com.github.davidmoten.rx.Actions
 
setAtomic(AtomicReference<T>) - Static method in class com.github.davidmoten.rx.Actions
 
setProducer(Producer) - Method in class com.github.davidmoten.rx.testing.TestSubscriber2
 
setToTrue0(AtomicBoolean) - Static method in class com.github.davidmoten.rx.Actions
 
setToTrue1(AtomicBoolean) - Static method in class com.github.davidmoten.rx.Actions
 
size() - Method in interface com.github.davidmoten.rx.buffertofile.DataSerializer
Returns the serialized length if constant other wise returns 0 to indicate variable length (which may force more copying in memory and be a bit slower).
size() - Method in class com.github.davidmoten.rx.internal.operators.FileBasedSPSCQueueMemoryMapped
 
size() - Method in class com.github.davidmoten.util.ByteArrayOutputStreamNoCopyUnsynchronized
Returns the current size of the buffer.
skipUnsubscribedCheck() - Method in class com.github.davidmoten.rx.testing.TestingHelper.CaseBuilder
 
solveWithNewtonsMethod(Func1<Double, Double>, Func1<Double, Double>, double) - Static method in class com.github.davidmoten.rx.Maths
 
solveWithNewtonsMethod(Func1<Double, Double>, double, double) - Static method in class com.github.davidmoten.rx.Maths
 
sort() - Static method in class com.github.davidmoten.rx.Transformers
 
sort(Comparator<? super T>) - Static method in class com.github.davidmoten.rx.Transformers
 
split(String, Pattern) - Static method in class com.github.davidmoten.rx.internal.operators.TransformerStringSplit
 
split(Observable<String>, String) - Static method in class com.github.davidmoten.rx.Strings
 
split(String) - Static method in class com.github.davidmoten.rx.Transformers
 
split(Pattern) - Static method in class com.github.davidmoten.rx.Transformers
 
splitLines(InputStream, Charset, String, String) - Static method in class com.github.davidmoten.rx.Strings
 
splitLines(InputStream, String) - Static method in class com.github.davidmoten.rx.Strings
 
StateMachine - Class in com.github.davidmoten.rx
 
stateMachine(Func0<State>, Func3<? super State, ? super In, ? super Subscriber<Out>, ? extends State>, Func2<? super State, ? super Subscriber<Out>, Boolean>, BackpressureStrategy) - Static method in class com.github.davidmoten.rx.Transformers
Returns a Observable.Transformer that allows processing of the source stream to be defined in a state machine where transitions of the state machine may also emit items to downstream that are buffered if necessary when backpressure is requested.
stateMachine(Func0<State>, Func3<? super State, ? super In, ? super Subscriber<Out>, ? extends State>, Func2<? super State, ? super Subscriber<Out>, Boolean>, BackpressureStrategy, int) - Static method in class com.github.davidmoten.rx.Transformers
 
stateMachine(Func0<? extends State>, Func3<? super State, ? super In, ? super Subscriber<Out>, ? extends State>, Func2<? super State, ? super Subscriber<Out>, Boolean>) - Static method in class com.github.davidmoten.rx.Transformers
Returns a Observable.Transformer that allows processing of the source stream to be defined in a state machine where transitions of the state machine may also emit items to downstream that are buffered if necessary when backpressure is requested.
stateMachine() - Static method in class com.github.davidmoten.rx.Transformers
 
StateMachine.Builder - Class in com.github.davidmoten.rx
 
StateMachine.Builder2<State> - Class in com.github.davidmoten.rx
 
StateMachine.Builder3<State,In,Out> - Class in com.github.davidmoten.rx
 
StateMachine.Completion<State,Out> - Interface in com.github.davidmoten.rx
 
StateMachine.Transition<State,In,Out> - Interface in com.github.davidmoten.rx
 
Statistics - Class in com.github.davidmoten.rx
 
string() - Static method in class com.github.davidmoten.rx.buffertofile.DataSerializers
 
Strings - Class in com.github.davidmoten.rx
 
Strings() - Constructor for class com.github.davidmoten.rx.Strings
 
strings(Observable<?>) - Static method in class com.github.davidmoten.rx.Strings
 
sum() - Method in class com.github.davidmoten.rx.Statistics
 
sumSquares() - Method in class com.github.davidmoten.rx.Statistics
 

T

TerminalEventTimeoutException() - Constructor for exception com.github.davidmoten.rx.testing.TestingHelper.TerminalEventTimeoutException
 
test() - Static method in class com.github.davidmoten.rx.testing.TestingHelper
Returns a Func1 For use with Observable.to().
TestingHelper - Class in com.github.davidmoten.rx.testing
Testing utility functions.
TestingHelper() - Constructor for class com.github.davidmoten.rx.testing.TestingHelper
 
TestingHelper.AssertionException - Exception in com.github.davidmoten.rx.testing
RuntimeException implementation to represent an assertion failure.
TestingHelper.Builder<T,R> - Class in com.github.davidmoten.rx.testing
Defines test cases and builds a JUnit test suite.
TestingHelper.CaseBuilder<T,R> - Class in com.github.davidmoten.rx.testing
 
TestingHelper.DeliveredMoreThanRequestedException - Exception in com.github.davidmoten.rx.testing
RuntimeException implementation to represent the situation of more items being delivered by a source than are requested via backpressure.
TestingHelper.DownstreamUnsubscriptionDidNotOccurException - Exception in com.github.davidmoten.rx.testing
 
TestingHelper.ExpectedErrorNotReceivedException - Exception in com.github.davidmoten.rx.testing
 
TestingHelper.ExpectedExceptionNotThrownException - Exception in com.github.davidmoten.rx.testing
 
TestingHelper.TerminalEventTimeoutException - Exception in com.github.davidmoten.rx.testing
 
TestingHelper.TooManyOnCompletedException - Exception in com.github.davidmoten.rx.testing
 
TestingHelper.UnexpectedOnCompletedException - Exception in com.github.davidmoten.rx.testing
 
TestingHelper.UnexpectedOnErrorException - Exception in com.github.davidmoten.rx.testing
 
TestingHelper.UnexpectedOnNextException - Exception in com.github.davidmoten.rx.testing
 
TestingHelper.UnsubscriptionFromSourceTimeoutException - Exception in com.github.davidmoten.rx.testing
 
TestingHelper.WrongOnNextCountException - Exception in com.github.davidmoten.rx.testing
 
TestSubscriber2<T> - Class in com.github.davidmoten.rx.testing
 
testSuite(Class<?>) - Method in class com.github.davidmoten.rx.testing.TestingHelper.Builder
Returns the JUnit TestSuite comprised of the test cases created so far.
testWithRequest(long) - Static method in class com.github.davidmoten.rx.testing.TestingHelper
Returns a Func1 For use with Observable.to().
throw0(RuntimeException) - Static method in class com.github.davidmoten.rx.Actions
 
throwable() - Method in class com.github.davidmoten.rx.RetryWhen.ErrorAndDuration
 
toArray() - Method in class com.github.davidmoten.rx.internal.operators.FileBasedSPSCQueueMemoryMapped
 
toArray(T[]) - Method in class com.github.davidmoten.rx.internal.operators.FileBasedSPSCQueueMemoryMapped
 
toByteArray() - Method in class com.github.davidmoten.util.ByteArrayOutputStreamNoCopyUnsynchronized
Creates a newly allocated byte array.
toByteArrayNoCopy() - Method in class com.github.davidmoten.util.ByteArrayOutputStreamNoCopyUnsynchronized
 
toComparator(Func2<? super T, ? super T, Integer>) - Static method in class com.github.davidmoten.rx.Functions
 
toFunc0(Callable<T>) - Static method in class com.github.davidmoten.rx.Functions
 
toFunc2(Comparator<? super T>) - Static method in class com.github.davidmoten.rx.Functions
 
toListUntil(Func1<? super T, Boolean>) - Static method in class com.github.davidmoten.rx.Transformers
Buffers the elements into continuous, non-overlapping Lists where the boundary is determined by a predicate receiving each item, after being buffered, and returns true to indicate a new buffer should start.
toListUntil(Func1<? super T, Boolean>, int) - Static method in class com.github.davidmoten.rx.Transformers
Buffers the elements into continuous, non-overlapping Lists where the boundary is determined by a predicate receiving each item, after being buffered, and returns true to indicate a new buffer should start.
toListUntilChanged() - Static method in class com.github.davidmoten.rx.Transformers
Returns a Observable.Transformer that returns an Observable that is a buffering of the source Observable into lists of sequential items that are equal.
toListWhile(Func2<? super List<T>, ? super T, Boolean>) - Static method in class com.github.davidmoten.rx.Transformers
Returns a Observable.Transformer that returns an Observable that is a buffering of the source Observable into lists of sequential items that satisfy the condition condition.
toListWhile(Func1<? super T, Boolean>) - Static method in class com.github.davidmoten.rx.Transformers
Buffers the elements into continuous, non-overlapping Lists where the boundary is determined by a predicate receiving each item, before or after being buffered, and returns true to indicate a new buffer should start.
toListWhile(Func1<? super T, Boolean>, int) - Static method in class com.github.davidmoten.rx.Transformers
Buffers the elements into continuous, non-overlapping Lists where the boundary is determined by a predicate receiving each item, before being buffered, and returns true to indicate a new buffer should start.
toObservable() - Method in class com.github.davidmoten.util.Optional
 
TooManyOnCompletedException() - Constructor for exception com.github.davidmoten.rx.testing.TestingHelper.TooManyOnCompletedException
 
TooManySubscribersException - Exception in com.github.davidmoten.rx.exceptions
 
TooManySubscribersException() - Constructor for exception com.github.davidmoten.rx.exceptions.TooManySubscribersException
 
toOperator(Func1<? super Observable<T>, ? extends Observable<R>>) - Static method in class com.github.davidmoten.rx.internal.operators.OperatorFromTransformer
 
toOperator(Func1<? super Observable<T>, ? extends Observable<R>>) - Static method in class com.github.davidmoten.rx.Transformers
 
toSet() - Static method in class com.github.davidmoten.rx.Transformers
 
toString() - Method in class com.github.davidmoten.rx.internal.operators.Permutations.Swap
 
toString() - Method in class com.github.davidmoten.rx.Statistics
 
toString() - Method in class com.github.davidmoten.rx.testing.TestSubscriber2
 
toString() - Method in class com.github.davidmoten.rx.util.MapWithIndex.Indexed
 
toString() - Method in class com.github.davidmoten.rx.util.Pair
 
toString() - Method in class com.github.davidmoten.util.ByteArrayOutputStreamNoCopyUnsynchronized
Converts the buffer's contents into a string decoding bytes using the platform's default character set.
toString(String) - Method in class com.github.davidmoten.util.ByteArrayOutputStreamNoCopyUnsynchronized
Converts the buffer's contents into a string by decoding the bytes using the named charset.
toString(int) - Method in class com.github.davidmoten.util.ByteArrayOutputStreamNoCopyUnsynchronized
Deprecated.
This method does not properly convert bytes into characters. As of JDK 1.1, the preferred way to do this is via the toString(String enc) method, which takes an encoding-name argument, or the toString() method, which uses the platform's default character encoding.
TransformerDecode - Class in com.github.davidmoten.rx.internal.operators
 
TransformerDecode() - Constructor for class com.github.davidmoten.rx.internal.operators.TransformerDecode
 
TransformerDelayFinalUnsubscribe<T> - Class in com.github.davidmoten.rx.internal.operators
 
TransformerDelayFinalUnsubscribe(long, Scheduler) - Constructor for class com.github.davidmoten.rx.internal.operators.TransformerDelayFinalUnsubscribe
 
TransformerLimitSubscribers<T> - Class in com.github.davidmoten.rx.internal.operators
 
TransformerLimitSubscribers(AtomicInteger, int) - Constructor for class com.github.davidmoten.rx.internal.operators.TransformerLimitSubscribers
 
TransformerOnBackpressureBufferRequestLimiting<T> - Class in com.github.davidmoten.rx.internal.operators
 
TransformerOnBackpressureBufferRequestLimiting() - Constructor for class com.github.davidmoten.rx.internal.operators.TransformerOnBackpressureBufferRequestLimiting
 
TransformerOnTerminateResume<T> - Class in com.github.davidmoten.rx.internal.operators
Switches to different Observables if the main source completes or signals an error.
TransformerOnTerminateResume(Func1<Throwable, Observable<T>>, Observable<T>) - Constructor for class com.github.davidmoten.rx.internal.operators.TransformerOnTerminateResume
 
Transformers - Class in com.github.davidmoten.rx
 
Transformers() - Constructor for class com.github.davidmoten.rx.Transformers
 
TransformerStateMachine<State,In,Out> - Class in com.github.davidmoten.rx.internal.operators
 
TransformerStringSplit - Class in com.github.davidmoten.rx.internal.operators
 
TransformerStringSplit() - Constructor for class com.github.davidmoten.rx.internal.operators.TransformerStringSplit
 
transition(StateMachine.Transition<State, In, Out>) - Method in class com.github.davidmoten.rx.StateMachine.Builder2
 
trim() - Static method in class com.github.davidmoten.rx.Strings
 

U

UnexpectedOnCompletedException() - Constructor for exception com.github.davidmoten.rx.testing.TestingHelper.UnexpectedOnCompletedException
 
UnexpectedOnErrorException() - Constructor for exception com.github.davidmoten.rx.testing.TestingHelper.UnexpectedOnErrorException
 
UnexpectedOnNextException(String) - Constructor for exception com.github.davidmoten.rx.testing.TestingHelper.UnexpectedOnNextException
 
unmarshal(List) - Method in class com.github.davidmoten.rx.Jaxws.ObservableAdapter
 
unsubscribe(Subscription) - Static method in class com.github.davidmoten.rx.Actions
 
unsubscribe() - Method in class com.github.davidmoten.rx.internal.operators.FileBasedSPSCQueueMemoryMapped
 
unsubscribeAfter(int) - Method in class com.github.davidmoten.rx.testing.TestingHelper.CaseBuilder
 
UnsubscriptionFromSourceTimeoutException() - Constructor for exception com.github.davidmoten.rx.testing.TestingHelper.UnsubscriptionFromSourceTimeoutException
 
unzip(File) - Static method in class com.github.davidmoten.rx.Bytes
 
unzip(InputStream) - Static method in class com.github.davidmoten.rx.Bytes
 
unzip(ZipInputStream) - Static method in class com.github.davidmoten.rx.Bytes
 

V

value() - Method in class com.github.davidmoten.rx.util.MapWithIndex.Indexed
 
valueOf(String) - Static method in enum com.github.davidmoten.rx.buffertofile.CacheType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.github.davidmoten.rx.internal.operators.OperatorWindowMinMax.Metric
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.github.davidmoten.rx.util.BackpressureStrategy
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.github.davidmoten.rx.buffertofile.CacheType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.github.davidmoten.rx.internal.operators.OperatorWindowMinMax.Metric
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.github.davidmoten.rx.util.BackpressureStrategy
Returns an array containing the constants of this enum type, in the order they are declared.

W

waitForMoreTerminalEvents(long, TimeUnit) - Method in class com.github.davidmoten.rx.testing.TestingHelper.Builder
Sets duration to wait for more terminal events after one has been received.
waitForMs() - Method in class com.github.davidmoten.rx.Processes.Parameters
 
waitForTerminalEvent(long, TimeUnit) - Method in class com.github.davidmoten.rx.testing.TestingHelper.Builder
Sets duration to wait for a terminal event (completed or error) when one is expected.
waitForUnsubscribe(long, TimeUnit) - Method in class com.github.davidmoten.rx.testing.TestingHelper.Builder
Sets duration to wait for unusubscription to occur (either of source or of downstream subscriber).
windowMax(int) - Static method in class com.github.davidmoten.rx.Transformers
 
windowMax(int, Comparator<? super T>) - Static method in class com.github.davidmoten.rx.Transformers
 
windowMin(int, Comparator<? super T>) - Static method in class com.github.davidmoten.rx.Transformers
 
windowMin(int) - Static method in class com.github.davidmoten.rx.Transformers
 
write(Observable<T>, File) - Method in class com.github.davidmoten.rx.Serialized.KryoBuilder
 
write(Observable<T>, File, boolean) - Method in class com.github.davidmoten.rx.Serialized.KryoBuilder
 
write(Observable<T>, File, boolean, int) - Method in class com.github.davidmoten.rx.Serialized.KryoBuilder
 
write(Observable<T>, ObjectOutputStream) - Static method in class com.github.davidmoten.rx.Serialized
Returns a duplicate of the input stream but with the side effect that emissions from the source are written to the ObjectOutputStream.
write(Observable<T>, File, boolean, int) - Static method in class com.github.davidmoten.rx.Serialized
Writes the source stream to the given file in given append mode and using the given buffer size.
write(Observable<T>, File, boolean) - Static method in class com.github.davidmoten.rx.Serialized
Writes the source stream to the given file in given append mode and using the a buffer size of 8192 bytes.
write(Observable<T>, File) - Static method in class com.github.davidmoten.rx.Serialized
Writes the source stream to the given file in given append mode and using the a buffer size of 8192 bytes.
write(int) - Method in class com.github.davidmoten.util.ByteArrayOutputStreamNoCopyUnsynchronized
Writes the specified byte to this byte array output stream.
write(byte[], int, int) - Method in class com.github.davidmoten.util.ByteArrayOutputStreamNoCopyUnsynchronized
Writes len bytes from the specified byte array starting at offset off to this byte array output stream.
writeTo(OutputStream) - Method in class com.github.davidmoten.util.ByteArrayOutputStreamNoCopyUnsynchronized
Writes the complete contents of this byte array output stream to the specified output stream argument, as if by calling the output stream's write method using out.write(buf, 0, count).
WrongOnNextCountException() - Constructor for exception com.github.davidmoten.rx.testing.TestingHelper.WrongOnNextCountException
 

Z

ZippedEntry - Class in com.github.davidmoten.rx.util
 
ZippedEntry(ZipEntry, InputStream) - Constructor for class com.github.davidmoten.rx.util.ZippedEntry
 
A B C D E F G H I J K L M N O P Q R S T U V W Z 
Skip navigation links

Copyright © 2013–2016. All rights reserved.