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

A

accept(Runnable[], Function<Runnable, Runnable>) - Method in class hu.akarnokd.rxjava3.debug.multihook.OnScheduleMultiHandlerManager
 
accept(T1, T2, T3) - Method in interface hu.akarnokd.rxjava3.functions.Consumer3
Consum the input parameters.
accept(T1, T2, T3, T4) - Method in interface hu.akarnokd.rxjava3.functions.Consumer4
Consum the input parameters.
accept(T1, T2, T3, T4, T5) - Method in interface hu.akarnokd.rxjava3.functions.Consumer5
Consum the input parameters.
accept(T1, T2, T3, T4, T5, T6) - Method in interface hu.akarnokd.rxjava3.functions.Consumer6
Consum the input parameters.
accept(T1, T2, T3, T4, T5, T6, T7) - Method in interface hu.akarnokd.rxjava3.functions.Consumer7
Consum the input parameters.
accept(T1, T2, T3, T4, T5, T6, T7, T8) - Method in interface hu.akarnokd.rxjava3.functions.Consumer8
Consum the input parameters.
accept(T1, T2, T3, T4, T5, T6, T7, T8, T9) - Method in interface hu.akarnokd.rxjava3.functions.Consumer9
Consum the input parameters.
accept(T1, T2) - Method in interface hu.akarnokd.rxjava3.functions.PlainBiConsumer
 
accept(T) - Method in interface hu.akarnokd.rxjava3.functions.PlainConsumer
 
add(Subscription) - Method in class hu.akarnokd.rxjava3.util.CompositeSubscription
 
AlwaysFalseBooleanSupplier - Enum in hu.akarnokd.rxjava3.util
A BooleanSupplier implementation that is always false.
AlwaysTrueBooleanSupplier - Enum in hu.akarnokd.rxjava3.util
A BooleanSupplier implementation that is always true.
amb(Iterable<? extends Nono>) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Returns a Nono that terminates when the first Nono from the sources sequence terminates.
amb(Iterable<? extends Perhaps<? extends T>>) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Emit the events of the Perhaps that reacts first.
amb(Iterable<? extends Solo<? extends T>>) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Emit the events of the Solo that reacts first.
ambArray(Nono...) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Returns a Nono that terminates when the first Nono from the array terminates.
ambArray(Perhaps<? extends T>...) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Emit the events of the Perhaps that reacts first.
ambArray(Solo<? extends T>...) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Emit the events of the Solo that reacts first.
ambWith(Perhaps<? extends T>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Signals the events of this or the other Perhaps whichever signals first.
ambWith(Solo<? extends T>) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Signal the events of this or the other Solo whichever signals first.
and(Observable<T2>) - Method in class hu.akarnokd.rxjava3.joins.JoinObservable
Returns a Pattern that matches when both Observables emit an item.
and(Observable<T3>) - Method in class hu.akarnokd.rxjava3.joins.Pattern2
Creates a pattern that matches when all three observable sequences have an available element.
and(Observable<T4>) - Method in class hu.akarnokd.rxjava3.joins.Pattern3
Creates a pattern that matches when all three observable sequences have an available element.
and(Observable<T5>) - Method in class hu.akarnokd.rxjava3.joins.Pattern4
Creates a pattern that matches when all four observable sequences have an available element.
and(Observable<T6>) - Method in class hu.akarnokd.rxjava3.joins.Pattern5
Creates a pattern that matches when all five observable sequences have an available element.
and(Observable<T7>) - Method in class hu.akarnokd.rxjava3.joins.Pattern6
Creates a pattern that matches when all six observable sequences have an available element.
and(Observable<T8>) - Method in class hu.akarnokd.rxjava3.joins.Pattern7
Creates a pattern that matches when all seven observable sequences have an available element.
and(Observable<T9>) - Method in class hu.akarnokd.rxjava3.joins.Pattern8
Creates a pattern that matches when all eight observable sequences have an available element.
and(Observable<? extends Object>) - Method in class hu.akarnokd.rxjava3.joins.Pattern9
Creates a pattern that matches when all nine observable sequences have an available element.
and(Observable<? extends Object>) - Method in class hu.akarnokd.rxjava3.joins.PatternN
Creates a pattern that matches when all previous observable sequences have an available element.
andThen(Publisher<? extends T>) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
When this Nono completes, it is continued by the events of the other Publisher.
andThen(Nono) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Run the other Nono when this Nono completes.
andThen(Nono) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Runs this Perhaps and then runs the other Nono source, only emitting this Perhaps' success value if the other Nono source completes normally.
andThen(Publisher<? extends T>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Runs this Perhaps and emits its value followed by running the other Publisher and emitting its values.
andThen(Nono) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Run the given Nono after this Solo completes successfully and emit that original success value only if the Nono completes normally.
andThen(Publisher<? extends T>) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Emits the success value of this Solo and then continues with the events of the other Publisher.
AnyValue - Enum in hu.akarnokd.rxjava3.async
Placeholder instance when one has to return something (and used to return null in 1.x).
append() - Method in class hu.akarnokd.rxjava3.debug.multihook.OnScheduleMultiHandlerManager
Adds the current non-null OnSchedule hook to this handler and replaces it in RxJavaPlugins with this OnScheduleMultiHandlerManager.
appendLast(Throwable) - Method in exception hu.akarnokd.rxjava3.debug.RxJavaAssemblyException
Try appending this RxJavaAssemblyException as the very last cause of the given throwable.
appendLast(Throwable) - Method in exception hu.akarnokd.rxjava3.functions.FunctionTagging.FunctionTaggingException
Try appending this FunctionTaggingException as the very last cause of the given throwable.
apply(Runnable) - Method in class hu.akarnokd.rxjava3.debug.multihook.OnScheduleMultiHandlerManager
 
apply(T1, T2) - Method in interface hu.akarnokd.rxjava3.functions.PlainBiFunction
 
apply(T) - Method in interface hu.akarnokd.rxjava3.functions.PlainFunction
 
apply(T1, T2, T3) - Method in interface hu.akarnokd.rxjava3.functions.PlainFunction3
 
apply(T1, T2, T3, T4) - Method in interface hu.akarnokd.rxjava3.functions.PlainFunction4
 
apply(T1, T2, T3, T4, T5) - Method in interface hu.akarnokd.rxjava3.functions.PlainFunction5
 
apply(T1, T2, T3, T4, T5, T6) - Method in interface hu.akarnokd.rxjava3.functions.PlainFunction6
 
apply(T1, T2, T3, T4, T5, T6, T7) - Method in interface hu.akarnokd.rxjava3.functions.PlainFunction7
 
apply(T1, T2, T3, T4, T5, T6, T7, T8) - Method in interface hu.akarnokd.rxjava3.functions.PlainFunction8
 
apply(T1, T2, T3, T4, T5, T6, T7, T8, T9) - Method in interface hu.akarnokd.rxjava3.functions.PlainFunction9
 
apply(Object, Object) - Method in enum hu.akarnokd.rxjava3.util.BiFunctionSecondIdentity
 
AsyncFlowable - Class in hu.akarnokd.rxjava3.async
Utility methods to convert functions and actions into asynchronous operations through the Publisher/Subscriber pattern.
AsyncObservable - Class in hu.akarnokd.rxjava3.async
Utility methods to convert functions and actions into asynchronous operations through the Observable/Observer pattern.
averageDouble(Publisher<? extends Number>) - Static method in class hu.akarnokd.rxjava3.math.MathFlowable
 
averageDouble(ObservableSource<? extends Number>) - Static method in class hu.akarnokd.rxjava3.math.MathObservable
 
averageFloat(Publisher<? extends Number>) - Static method in class hu.akarnokd.rxjava3.math.MathFlowable
 
averageFloat(ObservableSource<? extends Number>) - Static method in class hu.akarnokd.rxjava3.math.MathObservable
 

B

BasicEmitter<T> - Interface in hu.akarnokd.rxjava3.operators
Abstraction over a Subscriber.
BasicMergeSubscription<T> - Class in hu.akarnokd.rxjava3.operators
Subscription coordinator that merges items from a fixed set of source Publishers by picking the smallest available next item from them based on a Comparator.
BasicMergeSubscription(Subscriber<? super T>, Comparator<? super T>, int, int, boolean) - Constructor for class hu.akarnokd.rxjava3.operators.BasicMergeSubscription
 
BiFunctionSecondIdentity - Enum in hu.akarnokd.rxjava3.util
A BiFunction that returns its second parameter; use BiFunctionSecondIdentity.instance() to get a correctly typed (shared) instance.
blockingAwait() - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Blockingly await indefinitely the termination of this Nono and return the Throwable if this Nono terminated with an error, null otherwise.
blockingAwait(long, TimeUnit) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Blockingly await for the given timeout the termination of this Nono and return the Throwable if this Nono terminated with an error, null otherwise.
blockingGet() - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Blockingly awaits indefinitely the success value of this Perhaps or rethrows its error (wrapped into a RuntimeException if necessary).
blockingGet(long, TimeUnit) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Blockingly awaits at most the given timeout for the success value of this Perhaps or rethrows its error (wrapped into a RuntimeException if necessary).
blockingGet() - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Blockingly awaits indefinitely the success value of this Solo or rethrows its error (wrapped into a RuntimeException if necessary).
blockingGet(long, TimeUnit) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Blockingly awaits at most the given timeout for the success value of this Solo or rethrows its error (wrapped into a RuntimeException if necessary).
BlockingScheduler - Class in hu.akarnokd.rxjava3.schedulers
A Scheduler that uses the current thread, in an event-loop and blocking fashion to execute actions.
BlockingScheduler() - Constructor for class hu.akarnokd.rxjava3.schedulers.BlockingScheduler
 
blockingSubscribe() - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Block until this Nono terminates and ignore the actual events.
blockingSubscribe(Action) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Block until this Nono completes and call the Action on the thread where the blocking happens.
blockingSubscribe(Action, Consumer<? super Throwable>) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Block until this Nono terminates and call the Action or Consumer depending on the terminal event on the thread where the blocking happens.
blockingSubscribe() - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Blocks until this Perhaps terminates and ignores the signals it produced.
blockingSubscribe(Consumer<? super T>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Blocks until this Perhaps terminates and calls the onNext with the success value.
blockingSubscribe(Consumer<? super T>, Consumer<? super Throwable>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Blocks until this Perhaps terminates and calls the onNext with the success value or calls the onError with the error Throwable.
blockingSubscribe(Consumer<? super T>, Consumer<? super Throwable>, Action) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Blocks until this Perhaps produces its terminal signal and calls the appropriate callback(s) based on the signal type.
blockingSubscribe() - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Blocks until this Solo terminates and ignores the signals it produced.
blockingSubscribe(Consumer<? super T>) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Blocks until this Solo terminates and calls the onNext with the success value.
blockingSubscribe(Consumer<? super T>, Consumer<? super Throwable>) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Blocks until this solo terminates and calls the onNext with the success value or calls the onError with the error Throwable.
blockingSubscribe(Consumer<? super T>, Consumer<? super Throwable>, Action) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Blocks until this Solo produces its terminal signal and calls the appropriate callback(s) based on the signal type.
bufferSize() - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Returns the default buffer or prefetch size.
bufferSplit(Predicate<? super T>) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Buffers elements into a List until the given predicate returns true at which point a new empty buffer is started; the particular item will be dropped.
bufferSplit(Predicate<? super T>, Supplier<C>) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Buffers elements into a custom collection until the given predicate returns true at which point a new empty custom collection is started; the particular item will be dropped.
bufferUntil(Predicate<? super T>) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Buffers elements into a List until the given predicate returns true at which point a new empty buffer is started.
bufferUntil(Predicate<? super T>, Supplier<C>) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Buffers elements into a custom collection until the given predicate returns true at which point a new empty custom collection is started.
bufferWhile(Predicate<? super T>) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Buffers elements into a List while the given predicate returns true; if the predicate returns false for an item, a new buffer is created with the specified item.
bufferWhile(Predicate<? super T>, Supplier<C>) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Buffers elements into a custom collection while the given predicate returns true; if the predicate returns false for an item, a new collection is created with the specified item.
buildStackTrace() - Static method in exception hu.akarnokd.rxjava3.debug.RxJavaAssemblyException
 

C

cache() - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Caches the terminal event of the upstream Nono and relays/replays it to Subscribers.
cache() - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Caches the value or error event of the upstream Perhaps and relays/replays it to Subscribers.
cache() - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Caches the value or error event of the upstream Solo and relays/replays it to Subscribers.
cacheLast() - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Cache the very last value of the flow and relay/replay it to Subscribers.
call() - Method in interface hu.akarnokd.rxjava3.functions.SimpleCallable
 
cancel() - Method in class hu.akarnokd.rxjava3.operators.BasicMergeSubscription
 
cancel() - Method in class hu.akarnokd.rxjava3.util.CompositeSubscription
 
characters(CharSequence) - Static method in class hu.akarnokd.rxjava3.string.StringFlowable
Signals each character of the given string CharSequence as Integers.
characters(CharSequence) - Static method in class hu.akarnokd.rxjava3.string.StringObservable
Signals each character of the given string CharSequence as Integers.
cleanupItem(T) - Method in interface hu.akarnokd.rxjava3.operators.PartialCollectEmitter
Call the cleanup handler of the operator for a specific upstream instance.
clear() - Method in class hu.akarnokd.rxjava3.debug.multihook.MultiHandlerManager
Removes all handlers from this MultiHandlerManager.
clear() - Method in class hu.akarnokd.rxjava3.util.SpmcLinkedArrayQueue
 
clear() - Method in class hu.akarnokd.rxjava3.util.SpscOneQueue
 
coalesce(Supplier<R>, BiConsumer<R, T>) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Coalesces items from upstream into a container via a consumer and emits the container if there is a downstream demand, otherwise it keeps coalescing into the same container.
coalesce(Supplier<R>, BiConsumer<R, T>, int) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Coalesces items from upstream into a container via a consumer and emits the container if there is a downstream demand, otherwise it keeps coalescing into the same container.
compare(Comparable, Comparable) - Method in enum hu.akarnokd.rxjava3.util.SelfComparator
 
CompletableConsumers - Class in hu.akarnokd.rxjava3.consumers
Utility methods for creating and using consumers Completables.
Completables - Class in hu.akarnokd.rxjava3.operators
Additional operators in the form of CompletableConverters, use Completable.to(CompletableConverter) to apply the operators to an existing sequence.
CompletableTransformers - Class in hu.akarnokd.rxjava3.operators
Additional operators in the form of CompletableTransformer, use Completable.compose(CompletableTransformer) to apply the operators to an existing sequence.
complete() - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Returns a Nono that completes normally.
complete() - Method in interface hu.akarnokd.rxjava3.operators.PartialCollectEmitter
Indicate that no further output items will be produced.
compose(Function<? super Nono, ? extends Nono>) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Compose operators fluently via a function callback that returns a Nono for this Nono.
compose(Function<? super Perhaps<T>, ? extends Perhaps<R>>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Applies a function to this Perhaps and returns the Perhaps it returned.
compose(Function<? super Solo<T>, ? extends Solo<R>>) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Applies a function to this Solo and returns the Solo it returned.
CompositeSubscription - Class in hu.akarnokd.rxjava3.util
Container for Subscriptions and atomic operations on them.
CompositeSubscription() - Constructor for class hu.akarnokd.rxjava3.util.CompositeSubscription
 
concat(Iterable<? extends Nono>) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Runs the Nono sources one after the other.
concat(Publisher<? extends Nono>) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Runs the Nono sources emitted by the Publisher one after the other.
concat(Publisher<? extends Nono>, int) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Runs the Nono sources emitted by the Publisher one after the other, prefetching the given number of Nono sources.
concat(Iterable<? extends Perhaps<? extends T>>) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Concatenate the values in order from a sequence of Perhaps sources.
concat(Publisher<? extends Perhaps<? extends T>>) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Concatenate the values in order from a sequence of Perhaps sources.
concat(Publisher<? extends Perhaps<? extends T>>, int) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Concatenate the values in order from a sequence of Perhaps sources.
concat(Iterable<? extends Solo<? extends T>>) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Concatenate the values in order from a sequence of Solo sources.
concat(Publisher<? extends Solo<? extends T>>) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Concatenate the values in order from a sequence of Solo sources.
concat(Publisher<? extends Solo<? extends T>>, int) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Concatenate the values in order from a sequence of Solo sources.
concatArray(Nono...) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Runs the Nono sources one after the other.
concatArray(Perhaps<? extends T>...) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Concatenate the values in order from a sequence of Perhaps sources.
concatArray(Solo<? extends T>...) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Concatenate the values in order from a sequence of Solo sources.
concatArrayDelayError(Nono...) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Runs the Nono sources one after the other, delaying errors from them till all sources have terminated.
concatArrayDelayError(Perhaps<? extends T>...) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Concatenate the values in order from a sequence of Perhaps sources, delaying errors till all sources terminate.
concatArrayDelayError(Solo<? extends T>...) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Concatenate the values in order from a sequence of Solo sources, delaying errors till all sources terminate.
concatDelayError(Iterable<? extends Nono>) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Runs the Nono sources one after the other, delaying errors from them till all sources have terminated.
concatDelayError(Publisher<? extends Nono>) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Runs the Nono sources emitted by the Publisher, one after the other, delaying errors from them till all sources have terminated.
concatDelayError(Publisher<? extends Nono>, int, boolean) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Runs the Nono sources emitted by the Publisher, one after the other, delaying errors from them till all sources have terminated and prefetching Nonos from the upstream.
concatDelayError(Iterable<? extends Perhaps<? extends T>>) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Concatenate the values in order from a sequence of Perhaps sources, delaying errors till all sources terminate.
concatDelayError(Publisher<? extends Perhaps<? extends T>>) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Concatenate the values in order from a sequence of Perhaps sources, delaying errors till all sources terminate.
concatDelayError(Publisher<? extends Perhaps<? extends T>>, int) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Concatenate the values in order from a sequence of Perhaps sources, delaying errors till all sources terminate.
concatDelayError(Publisher<? extends Perhaps<? extends T>>, int, boolean) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Concatenate the values in order from a sequence of Perhaps sources, delaying errors till a source terminates or the whole sequence terminates.
concatDelayError(Iterable<? extends Solo<? extends T>>) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Concatenate the values in order from a sequence of Solo sources, delaying errors till all sources terminate.
concatDelayError(Publisher<? extends Solo<? extends T>>) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Concatenate the values in order from a sequence of Solo sources, delaying errors till all sources terminate.
concatDelayError(Publisher<? extends Solo<? extends T>>, int) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Concatenate the values in order from a sequence of Solo sources, delaying errors till all sources terminate.
concatDelayError(Publisher<? extends Solo<? extends T>>, int, boolean) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Concatenate the values in order from a sequence of Solo sources, delaying errors till a source terminates or the whole sequence terminates.
concatWith(Publisher<? extends T>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Runs this Perhaps and emits its value followed by running the other Publisher and emitting its values.
concatWith(Solo<T>) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Emits the success value of this Solo followed by the event of the other Solo.
Consumer3<T1,T2,T3> - Interface in hu.akarnokd.rxjava3.functions
Functional interface for a callback that consumes multipe values at the same and may throw a checked exception.
Consumer4<T1,T2,T3,T4> - Interface in hu.akarnokd.rxjava3.functions
Functional interface for a callback that consumes multipe values at the same and may throw a checked exception.
Consumer5<T1,T2,T3,T4,T5> - Interface in hu.akarnokd.rxjava3.functions
Functional interface for a callback that consumes multipe values at the same and may throw a checked exception.
Consumer6<T1,T2,T3,T4,T5,T6> - Interface in hu.akarnokd.rxjava3.functions
Functional interface for a callback that consumes multipe values at the same and may throw a checked exception.
Consumer7<T1,T2,T3,T4,T5,T6,T7> - Interface in hu.akarnokd.rxjava3.functions
Functional interface for a callback that consumes multipe values at the same and may throw a checked exception.
Consumer8<T1,T2,T3,T4,T5,T6,T7,T8> - Interface in hu.akarnokd.rxjava3.functions
Functional interface for a callback that consumes multipe values at the same and may throw a checked exception.
Consumer9<T1,T2,T3,T4,T5,T6,T7,T8,T9> - Interface in hu.akarnokd.rxjava3.functions
Functional interface for a callback that consumes multipe values at the same and may throw a checked exception.
create(CompletableOnSubscribe) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Creates a Nono instance that when subscribed to, the given onCreate is called for each individual subscriber to generate a terminal event synchronously and synchronously in a cancellation-safe manner.
create() - Static method in class hu.akarnokd.rxjava3.basetypes.NonoProcessor
Creates a NonoProcessor instance ready to receive events and Subscribers.
create(MaybeOnSubscribe<T>) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Create a Perhaps that for each incoming Subscriber calls a callback to emit a sync or async events in a thread-safe, backpressure-aware and cancellation-safe manner.
create() - Static method in class hu.akarnokd.rxjava3.basetypes.PerhapsProcessor
Creates a fresh PerhapsProcessor instance.
create(SingleOnSubscribe<T>) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Create a Solo that for each incoming Subscriber calls a callback to emit a sync or async events in a thread-safe, backpressure-aware and cancellation-safe manner.
create() - Static method in class hu.akarnokd.rxjava3.basetypes.SoloProcessor
Creates a fresh SoloProcessor instance.
create(Scheduler) - Static method in class hu.akarnokd.rxjava3.processors.DispatchWorkProcessor
Create an empty DispatchWorkProcessor instance with the given scheduler, default capacity hint (Flowable.bufferSize(), expected number of items cached until consumption) and delaying errors.
create(Scheduler, int) - Static method in class hu.akarnokd.rxjava3.processors.DispatchWorkProcessor
Create an empty DispatchWorkProcessor instance with the given scheduler, capacity hint (expected number of items cached until consumption) and delaying errors.
create(Scheduler, boolean) - Static method in class hu.akarnokd.rxjava3.processors.DispatchWorkProcessor
Create an empty DispatchWorkProcessor instance with the given scheduler, default capacity hint (Flowable.bufferSize(), expected number of items cached until consumption) and if an error should be delayed.
create(Scheduler, int, boolean) - Static method in class hu.akarnokd.rxjava3.processors.DispatchWorkProcessor
Create an empty DispatchWorkProcessor instance with the given scheduler, capacity hint (expected number of items cached until consumption) and if an error should be delayed.
create(Scheduler) - Static method in class hu.akarnokd.rxjava3.subjects.DispatchWorkSubject
Create an empty DispatchWorkSubject instance with the given scheduler, default capacity hint (Flowable.bufferSize(), expected number of items cached until consumption) and delaying errors.
create(Scheduler, int) - Static method in class hu.akarnokd.rxjava3.subjects.DispatchWorkSubject
Create an empty DispatchWorkSubject instance with the given scheduler, capacity hint (expected number of items cached until consumption) and delaying errors.
create(Scheduler, boolean) - Static method in class hu.akarnokd.rxjava3.subjects.DispatchWorkSubject
Create an empty DispatchWorkSubject instance with the given scheduler, default capacity hint (Flowable.bufferSize(), expected number of items cached until consumption) and if an error should be delayed.
create(Scheduler, int, boolean) - Static method in class hu.akarnokd.rxjava3.subjects.DispatchWorkSubject
Create an empty DispatchWorkSubject instance with the given scheduler, capacity hint (expected number of items cached until consumption) and if an error should be delayed.
create() - Static method in class hu.akarnokd.rxjava3.subjects.UnicastWorkSubject
Constructs an empty UnicastWorkSubject with the default capacity hint (expected number of cached items) of Flowable.bufferSize() and error delaying behavior.
create(int) - Static method in class hu.akarnokd.rxjava3.subjects.UnicastWorkSubject
Constructs an empty UnicastWorkSubject with the given capacity hint (expected number of cached items) and error delaying behavior.
create(boolean) - Static method in class hu.akarnokd.rxjava3.subjects.UnicastWorkSubject
Constructs an empty UnicastWorkSubject with the given capacity hint (expected number of cached items) of Flowable.bufferSize() and optional error delaying behavior.
create(int, boolean) - Static method in class hu.akarnokd.rxjava3.subjects.UnicastWorkSubject
Constructs an empty UnicastWorkSubject with the given capacity hint (expected number of cached items) and optional error delaying behavior.
createUnbounded(Scheduler) - Static method in class hu.akarnokd.rxjava3.processors.DispatchWorkProcessor
Create an empty, unbounded DispatchWorkProcessor instance with the given scheduler, default capacity hint (Flowable.bufferSize(), expected number of items cached until consumption) and delaying errors.
createUnbounded(Scheduler, int, boolean) - Static method in class hu.akarnokd.rxjava3.processors.DispatchWorkProcessor
Create an empty and unbounded DispatchWorkProcessor instance with the given scheduler, capacity hint (expected number of items cached until consumption) and if an error should be delayed.
createWorker() - Method in class hu.akarnokd.rxjava3.schedulers.BlockingScheduler
 
createWorker() - Method in class hu.akarnokd.rxjava3.schedulers.ParallelScheduler
 
createWorker() - Method in class hu.akarnokd.rxjava3.schedulers.SharedScheduler
 

D

debounceFirst(long, TimeUnit) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Debounces the upstream by taking an item and dropping subsequent items until the specified amount of time elapses after the last item, after which the process repeats.
debounceFirst(long, TimeUnit, Scheduler) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Debounces the upstream by taking an item and dropping subsequent items until the specified amount of time elapses after the last item, after which the process repeats.
defaultIfEmpty(T) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Signal the given item if this Perhaps is empty.
defer(Supplier<? extends Nono>) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Defers the creation of the actual Nono instance until a subscriber subscribes.
defer(Supplier<? extends Perhaps<? extends T>>) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Defers the creation of the actual Perhaps instance until subscription time and for each downstream Subscriber the given Supplier is called.
defer(Supplier<? extends Solo<T>>) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Defers the creation of the actual Solo to the time when a Subscriber subscribes to the returned Solo.
deferFuture(Supplier<? extends Future<? extends Publisher<? extends T>>>) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Returns an Observable that starts the specified asynchronous factory function whenever a new subscriber subscribes.
deferFuture(Supplier<? extends Future<? extends Publisher<? extends T>>>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Returns an Observable that starts the specified asynchronous factory function whenever a new subscriber subscribes.
deferFuture(Supplier<? extends Future<? extends ObservableSource<? extends T>>>) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Returns an Observable that starts the specified asynchronous factory function whenever a new subscriber subscribes.
deferFuture(Supplier<? extends Future<? extends ObservableSource<? extends T>>>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Returns an Observable that starts the specified asynchronous factory function whenever a new subscriber subscribes.
delay(long, TimeUnit) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Delay the emission of the terminal events of this Nono by the given time amount.
delay(long, TimeUnit, Scheduler) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Delay the emission of the terminal events of this Nono by the given time amount.
delay(long, TimeUnit) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Delay the emission of the signals of this Perhaps by the given amount of time.
delay(long, TimeUnit, Scheduler) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Delay the emission of the signals of this Perhaps by the given amount of time.
delay(Publisher<?>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Delay the emission of the signals of this Perhaps till the other Publisher signals an item or completes.
delay(long, TimeUnit) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Delay the emission of the signal of this Solo with the specified time amount.
delay(long, TimeUnit, Scheduler) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Delay the emission of the signal of this Solo with the specified time amount on the specified scheduler.
delay(Publisher<?>) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Delay the emission of the signal until the other Publisher signals an item or completes.
delaySubscription(Publisher<?>) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Delays the actual subscription to this Nono until the other Publisher signals an item or completes.
delaySubscription(long, TimeUnit) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Delays the actual subscription to this Nono until the given time passes.
delaySubscription(long, TimeUnit, Scheduler) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Delays the actual subscription to this Nono until the given time passes.
delaySubscription(long, TimeUnit) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Delay the subscription to this Perhaps by the given time amount.
delaySubscription(long, TimeUnit, Scheduler) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Delay the subscription to this Perhaps by the given time amount, running on the specified Scheduler.
delaySubscription(Publisher<?>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Delay the subscription to this Perhaps until the other Publisher signals an item or completes.
delaySubscription(Publisher<?>) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Delay the subscription to this Solo until the other Publisher signals a value or completes.
delaySubscription(long, TimeUnit) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Delay the subscription to this Solo until the specified delay elapses.
delaySubscription(long, TimeUnit, Scheduler) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Delay the subscription to this Solo until the specified delay elapses.
delete(Subscription) - Method in class hu.akarnokd.rxjava3.util.CompositeSubscription
 
demand() - Method in interface hu.akarnokd.rxjava3.operators.PartialCollectEmitter
Returns the number of items that can be emitted via PartialCollectEmitter.next(Object) without overflowing the downstream.
disable() - Method in class hu.akarnokd.rxjava3.debug.multihook.OnScheduleMultiHandlerManager
Disables this manager by restoring a null OnSchedule hook.
disable() - Static method in class hu.akarnokd.rxjava3.debug.RxJavaAssemblyTracking
Disable the assembly tracking.
disable() - Static method in class hu.akarnokd.rxjava3.debug.validator.RxJavaProtocolValidator
Disables the validation hooks be resetting the assembly hooks to none.
disable() - Static method in class hu.akarnokd.rxjava3.functions.FunctionTagging
Disable the function tagging wrappers in the tagX methods.
DispatchWorkProcessor<T> - Class in hu.akarnokd.rxjava3.processors
A FlowableProcessor variant that queues up items and dispatches them asynchronously so that one of the currently subscribed Subscribers can pick it up one by one, otherwise* cache it until at least an Subscriber subscribes.
DispatchWorkSubject<T> - Class in hu.akarnokd.rxjava3.subjects
A Subject variant that queues up items and dispatches them asynchronously so that one of the currently subscribed Observers can pick it up one by one, otherwise* cache it until at least an Observer subscribes.
DisposableFlowable<T> - Class in hu.akarnokd.rxjava3.async
A Flowable that also offers a means to dispose it, cancelling/disposing some shared underlying computation or resource via Disposable.dispose().
DisposableFlowable() - Constructor for class hu.akarnokd.rxjava3.async.DisposableFlowable
 
DisposableObservable<T> - Class in hu.akarnokd.rxjava3.async
A Observable that also offers a means to dispose it, cancelling/disposing some shared underlying computation or resource via Disposable.dispose().
DisposableObservable() - Constructor for class hu.akarnokd.rxjava3.async.DisposableObservable
 
dispose() - Method in class hu.akarnokd.rxjava3.processors.DispatchWorkProcessor
 
dispose() - Method in class hu.akarnokd.rxjava3.subjects.DispatchWorkSubject
 
dispose() - Method in class hu.akarnokd.rxjava3.subjects.UnicastWorkSubject
 
doAfterNext(Consumer<? super T>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Executes a callback after the value is emitted to downstream.
doAfterNext(Consumer<? super T>) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Executes a callback after the value is emitted to downstream.
doAfterTerminate(Action) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Executes the callback after this Nono terminates and the downstream is notified.
doAfterTerminate(Action) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Executes the callback after this Perhaps terminates and the downstream is notified.
doAfterTerminate(Action) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Executes the callback after this Solo terminates and the downstream is notified.
doComplete() - Method in interface hu.akarnokd.rxjava3.operators.BasicEmitter
 
doError(Throwable) - Method in interface hu.akarnokd.rxjava3.operators.BasicEmitter
 
doFinally(Action) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Executes the callback exactly if the upstream terminates or the downstream cancels the sequence.
doFinally(Action) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Executes the callback exactly if the upstream terminates or the downstream cancels the sequence.
doFinally(Action) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Executes the callback exactly if the upstream terminates or the downstream cancels the sequence.
doNext(T) - Method in interface hu.akarnokd.rxjava3.operators.BasicEmitter
 
doOnCancel(Action) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Executes the callback if the downstream cancels the sequence.
doOnCancel(Action) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Executes the callback if the downstream cancels the sequence.
doOnCancel(Action) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Executes the callback if the downstream cancels the sequence.
doOnComplete(Action) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Executes a callback when the upstream completes normally.
doOnComplete(Action) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Executes a callback when the upstream completes normally.
doOnComplete(Action) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Executes a callback when the upstream completes normally.
doOnError(Consumer<? super Throwable>) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Executes a callback when the upstream signals an error.
doOnError(Consumer<? super Throwable>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Executes a callback when the upstream signals an error.
doOnError(Consumer<? super Throwable>) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Executes a callback when the upstream signals an error.
doOnNext(Consumer<? super T>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Executes a callback before the value is emitted to downstream.
doOnNext(Consumer<? super T>) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Executes a callback before the value is emitted to downstream.
doOnRequest(LongConsumer) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Executes the callback when the downstream requests from this Nolo.
doOnRequest(LongConsumer) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Executes the callback when the downstream requests from this Perhaps.
doOnRequest(LongConsumer) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Executes the callback when the downstream requests from this Solo.
doOnSubscribe(Consumer<? super Subscription>) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Executes a callback when the upstream calls onSubscribe.
doOnSubscribe(Consumer<? super Subscription>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Executes a callback when the upstream calls onSubscribe.
doOnSubscribe(Consumer<? super Subscription>) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Executes a callback when the upstream calls onSubscribe.
doWhile(Publisher<? extends T>, BooleanSupplier) - Static method in class hu.akarnokd.rxjava3.expr.StatementFlowable
Return an Flowable that re-emits the emissions from the source Flowable, and then re-subscribes to the source long as a condition is true.
doWhile(ObservableSource<? extends T>, BooleanSupplier) - Static method in class hu.akarnokd.rxjava3.expr.StatementObservable
Return an Observable that re-emits the emissions from the source Observable, and then re-subscribes to the source long as a condition is true.
drain() - Method in class hu.akarnokd.rxjava3.operators.BasicMergeSubscription
 
dropItems(int) - Method in interface hu.akarnokd.rxjava3.operators.PartialCollectEmitter
Remove the first count items from the cache, sending them to the cleanup handler of the operator as well as possibly triggering more requests to the upstream to replenish the buffer.

E

empty() - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Returns an empty Perhaps.
emptyConsumer() - Static method in class hu.akarnokd.rxjava3.functions.FunctionsEx
Returns a Consumer1-9 shared instance that ignores the argument(s) of its accept() methods.
enable() - Method in class hu.akarnokd.rxjava3.debug.multihook.OnScheduleMultiHandlerManager
Enables this manager by replacing any existing OnSchedule hook in RxJavaPlugins.
enable() - Static method in class hu.akarnokd.rxjava3.debug.RxJavaAssemblyTracking
Enable the assembly tracking.
enable() - Static method in class hu.akarnokd.rxjava3.debug.validator.RxJavaProtocolValidator
Enable the protocol violation hooks.
enable() - Static method in class hu.akarnokd.rxjava3.functions.FunctionTagging
Enable the function tagging wrappers in the tagX methods.
enableAndChain() - Static method in class hu.akarnokd.rxjava3.debug.validator.RxJavaProtocolValidator
Enable the protocol violation hooks by chaining it before any existing hook.
error(Throwable) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Returns a Nono that signals the given Throwable to all subscribers.
error(Supplier<? extends Throwable>) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Returns a Nono that signals a Throwable generated by the supplier for each individual subscriber.
error(Throwable) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Returns a Perhaps that signals the given error to Subscribers.
error(Supplier<? extends Throwable>) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Returns a Perhaps that signals the error returned from the errorSupplier to each individual Subscriber.
error(Throwable) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Returns a Solo that signals the given error to Subscribers.
error(Supplier<? extends Throwable>) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Returns a Solo that signals the error returned from the errorSupplier to each individual Subscriber.
errorJump(FlowableTransformer<T, R>) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Allows an upstream error to jump over an inner transformation and is then reapplied once the inner transformation's returned Flowable terminates.
errorJump(ObservableTransformer<T, R>) - Static method in class hu.akarnokd.rxjava3.operators.ObservableTransformers
Allows an upstream error to jump over an inner transformation and is then reapplied once the inner transformation's returned Flowable terminates.
every(long) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Relays every Nth item from upstream.
execute() - Method in class hu.akarnokd.rxjava3.schedulers.BlockingScheduler
Begin executing the blocking event loop without any initial action.
execute(Action) - Method in class hu.akarnokd.rxjava3.schedulers.BlockingScheduler
Begin executing the blocking event loop with the given initial action (usually contain the rest of the 'main' method).
expand(Function<? super T, ? extends Publisher<? extends T>>) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Emits elements from the source and then expands them into another layer of Publishers, emitting those items recursively until all Publishers become empty in a depth-first manner.
expand(Function<? super T, ? extends Publisher<? extends T>>, ExpandStrategy) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Emits elements from the source and then expands them into another layer of Publishers, emitting those items recursively until all Publishers become empty with the specified strategy.
expand(Function<? super T, ? extends Publisher<? extends T>>, ExpandStrategy, int) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Emits elements from the source and then expands them into another layer of Publishers, emitting those items recursively until all Publishers become empty with the specified strategy.
expandDelayError(Function<? super T, ? extends Publisher<? extends T>>) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Emits elements from the source and then expands them into another layer of Publishers, emitting those items recursively until all Publishers become empty in a depth-first manner, delaying errors until all sources terminate.
expandDelayError(Function<? super T, ? extends Publisher<? extends T>>, ExpandStrategy) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Emits elements from the source and then expands them into another layer of Publishers, emitting those items recursively until all Publishers become empty with the specified strategy, delaying errors until all sources terminate.
expandDelayError(Function<? super T, ? extends Publisher<? extends T>>, ExpandStrategy, int) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Emits elements from the source and then expands them into another layer of Publishers, emitting those items recursively until all Publishers become empty with the specified strategy, delaying errors until all sources terminate.
ExpandStrategy - Enum in hu.akarnokd.rxjava3.operators
Represents the strategies for recursive expansion with the expand() operator.

F

fillInStackTrace() - Method in exception hu.akarnokd.rxjava3.debug.RxJavaAssemblyException
 
fillInStackTrace() - Method in exception hu.akarnokd.rxjava3.functions.FunctionTagging.FunctionTaggingException
 
filter(Predicate<? super T>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Filters the value from upstream with a predicate and completes if the filter didn't match it.
filter(Predicate<? super T>) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Applies a predicate to the value and emits it if the predicate returns true, completes otherwise.
filterAsync(Function<? super T, ? extends Publisher<Boolean>>) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Maps each upstream value into a single true or false value provided by a generated Publisher for that input value and emits the input value if the inner Publisher returned true.
filterAsync(Function<? super T, ? extends Publisher<Boolean>>, int) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Maps each upstream value into a single true or false value provided by a generated Publisher for that input value and emits the input value if the inner Publisher returned true.
filterAsync(Function<? super T, ? extends ObservableSource<Boolean>>) - Static method in class hu.akarnokd.rxjava3.operators.ObservableTransformers
Maps each upstream value into a single true or false value provided by a generated ObservableSource for that input value and emits the input value if the inner ObservableSource returned true.
filterAsync(Function<? super T, ? extends ObservableSource<Boolean>>, int) - Static method in class hu.akarnokd.rxjava3.operators.ObservableTransformers
Maps each upstream value into a single true or false value provided by a generated ObservableSource for that input value and emits the input value if the inner ObservableSource returned true.
find(Throwable) - Static method in exception hu.akarnokd.rxjava3.debug.RxJavaAssemblyException
Tries to locate the RxJavaAssemblyException in the chain of causes of the given Throwable.
flatMap(Function<? super Throwable, ? extends Publisher<? extends T>>, Supplier<? extends Publisher<? extends T>>) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Maps the upstream completion or error into a Publisher and emit its events as a Flowable.
flatMap(Function<? super T, ? extends Perhaps<? extends R>>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Maps the upstream's value into another Perhaps and emits its resulting events.
flatMap(Function<? super T, ? extends Perhaps<? extends R>>, Function<? super Throwable, ? extends Perhaps<? extends R>>, Supplier<? extends Perhaps<? extends R>>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Maps the upstream events into other Perhaps instances and emits its resulting events.
flatMap(Function<? super T, ? extends Solo<? extends R>>) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Maps the success value of this Solo into another Solo and emits its signals.
flatMap(Function<? super T, ? extends Solo<? extends R>>, Function<? super Throwable, ? extends Solo<? extends R>>) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Maps the success value or the failure of this Solo into another Solo and emits its signal.
flatMap(Supplier<? extends CompletableSource>, Function<? super Throwable, ? extends CompletableSource>) - Static method in class hu.akarnokd.rxjava3.operators.CompletableTransformers
Maps the terminal signals of the upstream into CompletableSources and subscribes to it, relaying its terminal events to the downstream.
flatMap(Function<? super T, ? extends MaybeSource<? extends R>>, Function<? super Throwable, ? extends MaybeSource<? extends R>>, Supplier<? extends MaybeSource<? extends R>>) - Static method in class hu.akarnokd.rxjava3.operators.MaybeTransformers
Maps the terminal signals of the upstream into MaybeSources and subscribes to it, relaying its terminal events to the downstream.
flatMap(Function<? super T, ? extends SingleSource<? extends R>>, Function<? super Throwable, ? extends SingleSource<? extends R>>) - Static method in class hu.akarnokd.rxjava3.operators.SingleTransformers
Maps the terminal signals of the upstream into SingleSources and subscribes to it, relaying its terminal events to the downstream.
flatMapAsync(Function<? super T, ? extends Publisher<? extends R>>, Scheduler) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Maps the upstream values into Publisher and merges at most 32 of them at once, collects and emits the items on the specified scheduler.
flatMapAsync(Function<? super T, ? extends Publisher<? extends R>>, Scheduler, boolean) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Maps the upstream values into Publisher and merges at most 32 of them at once, collects and emits the items on the specified scheduler.
flatMapAsync(Function<? super T, ? extends Publisher<? extends R>>, Scheduler, int, int, boolean) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Maps the upstream values into Publisher and merges at most 32 of them at once, collects and emits the items on the specified scheduler.
flatMapCompletable(Function<? super T, ? extends CompletableSource>, Function<? super Throwable, ? extends CompletableSource>, Supplier<? extends CompletableSource>) - Static method in class hu.akarnokd.rxjava3.operators.Maybes
Maps the terminal signals of the upstream into CompletableSources and subscribes to it, relaying its terminal events to the downstream.
flatMapCompletable(Function<? super T, ? extends CompletableSource>, Function<? super Throwable, ? extends CompletableSource>) - Static method in class hu.akarnokd.rxjava3.operators.Singles
Maps the terminal signals of the upstream into CompletableSources and subscribes to it, relaying its terminal events to the downstream.
flatMapDrop(Function<? super T, ? extends ObservableSource<? extends R>>) - Static method in class hu.akarnokd.rxjava3.operators.ObservableTransformers
FlatMap only one ObservableSource at a time and ignore upstream values until it terminates.
flatMapFlowable(Supplier<? extends Publisher<? extends R>>, Function<? super Throwable, ? extends Publisher<? extends R>>) - Static method in class hu.akarnokd.rxjava3.operators.Completables
Maps the terminal signals of the upstream into Publishers and subscribes to it, relaying its terminal events to the downstream.
flatMapFlowable(Function<? super T, ? extends Publisher<? extends R>>, Function<? super Throwable, ? extends Publisher<? extends R>>, Supplier<? extends Publisher<? extends R>>) - Static method in class hu.akarnokd.rxjava3.operators.Maybes
Maps the terminal signals of the upstream into Publishers and subscribes to it, relaying its terminal events to the downstream.
flatMapFlowable(Function<? super T, ? extends Publisher<? extends R>>, Function<? super Throwable, ? extends Publisher<? extends R>>) - Static method in class hu.akarnokd.rxjava3.operators.Singles
Maps the terminal signals of the upstream into Publishers and subscribes to it, relaying its terminal events to the downstream.
flatMapLatest(Function<? super T, ? extends ObservableSource<? extends R>>) - Static method in class hu.akarnokd.rxjava3.operators.ObservableTransformers
FlatMap only one ObservableSource at a time and keep the latest upstream value until it terminates and resume with the ObservableSource mapped for that latest upstream value.
flatMapMaybe(Supplier<? extends MaybeSource<? extends R>>, Function<? super Throwable, ? extends MaybeSource<? extends R>>) - Static method in class hu.akarnokd.rxjava3.operators.Completables
Maps the terminal signals of the upstream into MaybeSources and subscribes to it, relaying its terminal events to the downstream.
flatMapMaybe(Function<? super T, ? extends MaybeSource<? extends R>>, Function<? super Throwable, ? extends MaybeSource<? extends R>>) - Static method in class hu.akarnokd.rxjava3.operators.Singles
Maps the terminal signals of the upstream into MaybeSources and subscribes to it, relaying its terminal events to the downstream.
flatMapObservable(Supplier<? extends ObservableSource<? extends R>>, Function<? super Throwable, ? extends ObservableSource<? extends R>>) - Static method in class hu.akarnokd.rxjava3.operators.Completables
Maps the terminal signals of the upstream into ObservableSources and subscribes to it, relaying its terminal events to the downstream.
flatMapObservable(Function<? super T, ? extends ObservableSource<? extends R>>, Function<? super Throwable, ? extends ObservableSource<? extends R>>, Supplier<? extends ObservableSource<? extends R>>) - Static method in class hu.akarnokd.rxjava3.operators.Maybes
Maps the terminal signals of the upstream into ObservableSources and subscribes to it, relaying its terminal events to the downstream.
flatMapObservable(Function<? super T, ? extends ObservableSource<? extends R>>, Function<? super Throwable, ? extends ObservableSource<? extends R>>) - Static method in class hu.akarnokd.rxjava3.operators.Singles
Maps the terminal signals of the upstream into ObservableSources and subscribes to it, relaying its terminal events to the downstream.
flatMapPublisher(Function<? super T, ? extends Publisher<? extends R>>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Maps the upstream value into a Publisher and emits all of its events.
flatMapPublisher(Function<? super T, ? extends Publisher<? extends R>>) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Maps the success value of this Solo into a Publisher and emits its signals.
flatMapSingle(Supplier<? extends SingleSource<? extends R>>, Function<? super Throwable, ? extends SingleSource<? extends R>>) - Static method in class hu.akarnokd.rxjava3.operators.Completables
Maps the terminal signals of the upstream into SingleSources and subscribes to it, relaying its terminal events to the downstream.
flatMapSingle(Function<? super T, ? extends SingleSource<? extends R>>, Function<? super Throwable, ? extends SingleSource<? extends R>>, Supplier<? extends SingleSource<? extends R>>) - Static method in class hu.akarnokd.rxjava3.operators.Maybes
Maps the terminal signals of the upstream into SingleSources and subscribes to it, relaying its terminal events to the downstream.
flatMapSync(Function<? super T, ? extends Publisher<? extends R>>) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Maps the upstream values into Publisher and merges at most 32 of them at once, optimized for mainly synchronous sources.
flatMapSync(Function<? super T, ? extends Publisher<? extends R>>, boolean) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Maps the upstream values into Publisher and merges at most maxConcurrency of them at once, optimized for mainly synchronous sources.
flatMapSync(Function<? super T, ? extends Publisher<? extends R>>, int, int, boolean) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Maps the upstream values into Publisher and merges at most maxConcurrency of them at once, optimized for mainly synchronous sources.
FlowableAsyncEmitter<T> - Interface in hu.akarnokd.rxjava3.operators
Provides an API on top of the Emitter signals that allow setting and replacing a Cancellable resource to be cancelled when the associated flow is cancelled.
FlowableConsumers - Class in hu.akarnokd.rxjava3.consumers
Utility methods for creating and using consumers Flowables.
FlowableProcessors - Class in hu.akarnokd.rxjava3.processors
Utility methods to work with Reactive-Streams Processors and RxJava 2 FlowableProcessors.
Flowables - Class in hu.akarnokd.rxjava3.operators
Utility class to create Flowable sources.
FlowableTransformers - Class in hu.akarnokd.rxjava3.operators
Additional operators in the form of FlowableTransformer, use Flowable.compose(FlowableTransformer) to apply the operators to an existing sequence.
forEach(Consumer<H>) - Method in class hu.akarnokd.rxjava3.debug.multihook.MultiHandlerManager
The given consumer is invoked with each registered handler instance.
forEach(S, BiConsumer<S, H>) - Method in class hu.akarnokd.rxjava3.debug.multihook.MultiHandlerManager
The given consumer is invoked with each registered handler instance.
forEachFuture(Publisher<? extends T>, Consumer<? super T>) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Subscribes to the given source and calls the callback for each emitted item, and surfaces the completion or error through a Future.
forEachFuture(Publisher<? extends T>, Consumer<? super T>, Consumer<? super Throwable>) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Subscribes to the given source and calls the callback for each emitted item, and surfaces the completion or error through a Future.
forEachFuture(Publisher<? extends T>, Consumer<? super T>, Consumer<? super Throwable>, Action) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Subscribes to the given source and calls the callback for each emitted item, and surfaces the completion or error through a Future.
forEachFuture(Publisher<? extends T>, Consumer<? super T>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Subscribes to the given source and calls the callback for each emitted item, and surfaces the completion or error through a Future, scheduled on the given scheduler.
forEachFuture(Publisher<? extends T>, Consumer<? super T>, Consumer<? super Throwable>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Subscribes to the given source and calls the callback for each emitted item, and surfaces the completion or error through a Future, scheduled on the given Scheduler.
forEachFuture(Publisher<? extends T>, Consumer<? super T>, Consumer<? super Throwable>, Action, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Subscribes to the given source and calls the callback for each emitted item, and surfaces the completion or error through a Future, scheduled on the given Scheduler.
forEachFuture(ObservableSource<? extends T>, Consumer<? super T>) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Subscribes to the given source and calls the callback for each emitted item, and surfaces the completion or error through a Future.
forEachFuture(ObservableSource<? extends T>, Consumer<? super T>, Consumer<? super Throwable>) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Subscribes to the given source and calls the callback for each emitted item, and surfaces the completion or error through a Future.
forEachFuture(ObservableSource<? extends T>, Consumer<? super T>, Consumer<? super Throwable>, Action) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Subscribes to the given source and calls the callback for each emitted item, and surfaces the completion or error through a Future.
forEachFuture(ObservableSource<? extends T>, Consumer<? super T>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Subscribes to the given source and calls the callback for each emitted item, and surfaces the completion or error through a Future, scheduled on the given scheduler.
forEachFuture(ObservableSource<? extends T>, Consumer<? super T>, Consumer<? super Throwable>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Subscribes to the given source and calls the callback for each emitted item, and surfaces the completion or error through a Future, scheduled on the given Scheduler.
forEachFuture(ObservableSource<? extends T>, Consumer<? super T>, Consumer<? super Throwable>, Action, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Subscribes to the given source and calls the callback for each emitted item, and surfaces the completion or error through a Future, scheduled on the given Scheduler.
from(Observable<T>) - Static method in class hu.akarnokd.rxjava3.joins.JoinObservable
Creates a JoinObservable from a regular Observable.
fromAction(Action) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Executes an action when a subscriber subscribes to the returned Nono.
fromAction(Action) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Run an action for each individual Subscriber and terminate.
fromCallable(Callable<T>) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Runs a Callable and emits its resulting value or its exception; null is considered to be an indication for an empty Perhaps.
fromCallable(Callable<T>) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Returns a Solo that calls the callable and emits its value or error.
fromCompletable(CompletableSource) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Wrap a Completable into a Nono and terminate when the source Completable terminates.
fromCompletable(CompletableSource) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Wraps a Completable and signals its terminal events.
fromFuture(Future<?>) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Blockingly waits indefinitely for the given Future to terminate, relaying any error the Future signals.
fromFuture(Future<?>, long, TimeUnit) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Blockingly waits the given Future for the given timeout to terminate, relaying any error the Future signals.
fromFuture(Future<? extends T>) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
When subscribed, the future is awaited blockingly and indefinitely for its result value; null result will yield a NoSuchElementException.
fromFuture(Future<? extends T>, long, TimeUnit) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
When subscribed, the future is awaited blockingly for a given amount of time for its result value; null result will yield a NoSuchElementException and a timeout will yield a TimeoutException.
fromFuture(Future<? extends T>) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
When subscribed, the future is awaited blockingly and indefinitely for its result value; null result will yield a NoSuchElementException.
fromFuture(Future<? extends T>, long, TimeUnit) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
When subscribed, the future is awaited blockingly for a given amount of time for its result value; null result will yield a NoSuchElementException and a timeout will yield a TimeoutException.
fromMaybe(MaybeSource<?>) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Wrap a Maybe, ignore its success value and terminate if the source Maybe terminates.
fromMaybe(MaybeSource<T>) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Wraps a Maybe and signals its events.
fromObservable(ObservableSource<?>) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Wrap a general Observable, ignore all of its values and terminate if the source Observable terminates.
fromPublisher(Publisher<?>) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Wrap a general Publisher, ignore all of its values and terminate if the source Publisher terminates.
fromPublisher(Publisher<T>) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Wraps a Publisher and signals its single value or completion signal or signals IndexOutOfBoundsException if the Publisher has more than one element.
fromPublisher(Publisher<T>) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Wraps a Publisher into a Solo and signals its only value, NoSuchElementException if empty or IndexOutOfBoundsException if it has more than one element.
fromSingle(SingleSource<?>) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Wrap a Single, ignore its success value and terminate if the source Single terminates.
fromSingle(SingleSource<T>) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Wraps a Single and signals its events.
fromSingle(SingleSource<T>) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Wraps a Single into a Solo and signals its events.
FunctionsEx - Class in hu.akarnokd.rxjava3.functions
Utility methods to work with functional interfaces of this package.
FunctionTagging - Class in hu.akarnokd.rxjava3.functions
Wraps the regular io.reactivex.functions function types and appends the user-specified tag to the exception the wrapped function produces.
FunctionTagging.FunctionTaggingException - Exception in hu.akarnokd.rxjava3.functions
The stackless tagging exception appended to the chain of causes of the original exception thrown by the wrapped function.
FunctionTaggingException(String) - Constructor for exception hu.akarnokd.rxjava3.functions.FunctionTagging.FunctionTaggingException
Constructs a FunctionTaggingException with the given message.

G

generateAsync(Supplier<S>, BiFunction<S, FlowableAsyncEmitter<T>, S>, Consumer<? super S>) - Static method in class hu.akarnokd.rxjava3.operators.Flowables
Generates items by invoking a callback, for each downstream request one by one, that sets up an asynchronous call to some API that eventually responds with an item, an error or termination, while making sure there is only one such outstanding API call in progress and honoring the backpressure of the downstream.
getAccumulator() - Method in interface hu.akarnokd.rxjava3.operators.PartialCollectEmitter
Returns an optional, user-defined accumulator that can be used to aggregate partial items from upstream until enough data has been gathered.
getAsBoolean() - Method in enum hu.akarnokd.rxjava3.util.AlwaysFalseBooleanSupplier
 
getAsBoolean() - Method in enum hu.akarnokd.rxjava3.util.AlwaysTrueBooleanSupplier
 
getIndex() - Method in interface hu.akarnokd.rxjava3.operators.PartialCollectEmitter
Reads an optional, user-defined index that can be used to store a read pointer into the very first upstream item accessible via PartialCollectEmitter.getItem(int) to indicate from where to resume.
getItem(int) - Method in interface hu.akarnokd.rxjava3.operators.PartialCollectEmitter
Access a cached item based on an index less than PartialCollectEmitter.size().
getMessage() - Method in exception hu.akarnokd.rxjava3.debug.RxJavaAssemblyException
 
getOnAssemblyHandler() - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Returns the current onAssembly handler function or null if not set.
getOnAssemblyHandler() - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Returns the current onAssembly handler.
getOnAssemblyHandler() - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Returns the current onAssembly handler.
getOnViolationHandler() - Static method in class hu.akarnokd.rxjava3.debug.validator.RxJavaProtocolValidator
Returns the current custom violation callback handler.
getThrowable() - Method in class hu.akarnokd.rxjava3.basetypes.NonoProcessor
Returns the error that terminated this NonoProcessor if NonoProcessor.hasThrowable() returns true.
getThrowable() - Method in class hu.akarnokd.rxjava3.basetypes.PerhapsProcessor
Returns the received onError Throwable if hasThrowable() is true, null otherwise.
getThrowable() - Method in class hu.akarnokd.rxjava3.basetypes.SoloProcessor
Returns the received onError Throwable if hasThrowable() is true, null otherwise.
getThrowable() - Method in class hu.akarnokd.rxjava3.processors.DispatchWorkProcessor
 
getThrowable() - Method in class hu.akarnokd.rxjava3.subjects.DispatchWorkSubject
 
getThrowable() - Method in class hu.akarnokd.rxjava3.subjects.UnicastWorkSubject
 
getValue() - Method in class hu.akarnokd.rxjava3.basetypes.PerhapsProcessor
Returns the received onNext value if hasValue() is true, null otherwise.
getValue() - Method in class hu.akarnokd.rxjava3.basetypes.SoloProcessor
Returns the received onNext value if hasValue() is true, null otherwise.

H

handlers - Variable in class hu.akarnokd.rxjava3.debug.multihook.MultiHandlerManager
The copy-on-write registry of handlers wrapped into a HandlerRegistration container to support disposing/unregistering a particular registration.
hasComplete() - Method in class hu.akarnokd.rxjava3.basetypes.NonoProcessor
Returns true if this NonoProcessor has completed normally.
hasComplete() - Method in class hu.akarnokd.rxjava3.basetypes.PerhapsProcessor
Returns true if this PerhapsProcessor completed without any value.
hasComplete() - Method in class hu.akarnokd.rxjava3.processors.DispatchWorkProcessor
 
hasComplete() - Method in class hu.akarnokd.rxjava3.subjects.DispatchWorkSubject
 
hasComplete() - Method in class hu.akarnokd.rxjava3.subjects.UnicastWorkSubject
 
hasHandlers() - Method in class hu.akarnokd.rxjava3.debug.multihook.MultiHandlerManager
Returns true if this manager has any handlers registered.
hasObservers() - Method in class hu.akarnokd.rxjava3.subjects.DispatchWorkSubject
 
hasObservers() - Method in class hu.akarnokd.rxjava3.subjects.UnicastWorkSubject
 
hasSubscribers() - Method in class hu.akarnokd.rxjava3.basetypes.NonoProcessor
Returns true if this NonoProcessor currently has Subscribers.
hasSubscribers() - Method in class hu.akarnokd.rxjava3.basetypes.PerhapsProcessor
Returns true if this Processor has Subscribers.
hasSubscribers() - Method in class hu.akarnokd.rxjava3.basetypes.SoloProcessor
Returns true if this Processor has Subscribers.
hasSubscribers() - Method in class hu.akarnokd.rxjava3.processors.DispatchWorkProcessor
 
hasThrowable() - Method in class hu.akarnokd.rxjava3.basetypes.NonoProcessor
Returns true if this NonoProcessor has terminated with an error.
hasThrowable() - Method in class hu.akarnokd.rxjava3.basetypes.PerhapsProcessor
Returns true if this PerhapsProcessor received an onError Throwable.
hasThrowable() - Method in class hu.akarnokd.rxjava3.basetypes.SoloProcessor
Returns true if this SoloProcessor received an onError Throwable.
hasThrowable() - Method in class hu.akarnokd.rxjava3.processors.DispatchWorkProcessor
 
hasThrowable() - Method in class hu.akarnokd.rxjava3.subjects.DispatchWorkSubject
 
hasThrowable() - Method in class hu.akarnokd.rxjava3.subjects.UnicastWorkSubject
 
hasValue() - Method in class hu.akarnokd.rxjava3.basetypes.PerhapsProcessor
Returns true if this PerhapsProcessor received an onNext value.
hasValue() - Method in class hu.akarnokd.rxjava3.basetypes.SoloProcessor
Returns true if this SoloProcessor received an onNext value.
hide() - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Hides the identity of this Nono.
hide() - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Hides the identity of this Perhaps instance, including its subscriber.
hide() - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Hides the identity of this Solo, including its Subscription and allows preventing fusion and other optimizations for diagnostic purposes.
hu.akarnokd.rxjava3.async - package hu.akarnokd.rxjava3.async
Utility methods to jumpstart a reactive sequence via AsyncFlowable and AsyncObservable; port of the RxJavaAsyncUtil library.
hu.akarnokd.rxjava3.basetypes - package hu.akarnokd.rxjava3.basetypes
Proof-of-concept backpressure enabled 0..1 element reactive types: Solo, Perhaps and Nono.
hu.akarnokd.rxjava3.consumers - package hu.akarnokd.rxjava3.consumers
Utility methods to create special consumer types, such as auto-release consumers via FlowableConsumers, ObservableConsumers, MaybeConsumers, SingleConsumers and CompletableConsumers.
hu.akarnokd.rxjava3.debug - package hu.akarnokd.rxjava3.debug
Debugging support to remember where operators have been created in the code via RxJavaPlugins' assembly hooks, enabled via RxJavaAssemblyTracking.
hu.akarnokd.rxjava3.debug.multihook - package hu.akarnokd.rxjava3.debug.multihook
Proof of concept RxJavaPlugins hook implementation for handling multiple hooks to the onSchedule callback via OnScheduleMultiHandlerManager.
hu.akarnokd.rxjava3.debug.validator - package hu.akarnokd.rxjava3.debug.validator
Protocol validation support via RxJavaPlugins hook implementations enalbed via RxJavaProtocolValidator.
hu.akarnokd.rxjava3.expr - package hu.akarnokd.rxjava3.expr
Utility methods for computational expressions and statements via StatementFlowable and StatementObservable; a port of the RxJavaComputationExpression library.
hu.akarnokd.rxjava3.functions - package hu.akarnokd.rxjava3.functions
Functional interface definitions for Consumers with 3..9 arguments and Functions without the throws Exception clause in their definition.
hu.akarnokd.rxjava3.joins - package hu.akarnokd.rxjava3.joins
Utility methods for join patterns (more generic way than combineLatest) via JoinObservable wrapper and the and/then/when vocabulary; a port of the RxJavaJoins library.
hu.akarnokd.rxjava3.math - package hu.akarnokd.rxjava3.math
Utility methods for aggregating and reducing flows with numeric content via MathFlowable and MathObservable; a port of the RxJavaMath library.
hu.akarnokd.rxjava3.operators - package hu.akarnokd.rxjava3.operators
Utility methods for uncommon, custom, special and exotic operators for RxJava flows in the form of transformers and converters.
hu.akarnokd.rxjava3.parallel - package hu.akarnokd.rxjava3.parallel
Utility methods for parallel aggregation and reduction for ParallelFlowables via ParallelTransformers.
hu.akarnokd.rxjava3.processors - package hu.akarnokd.rxjava3.processors
Special processors such as DispatchWorkProcessor and generic utilities for FlowableProcessors via FlowableProcessors methods.
hu.akarnokd.rxjava3.schedulers - package hu.akarnokd.rxjava3.schedulers
Special scheduler implementations, such as BlockingScheduler, ParallelScheduler and SharedScheduler.
hu.akarnokd.rxjava3.string - package hu.akarnokd.rxjava3.string
Utility methods working with strings and character sequences via StringFlowable and StringObservable; a partial port of the RxJavaString library.
hu.akarnokd.rxjava3.subjects - package hu.akarnokd.rxjava3.subjects
Special subjects such as UnicastWorkSubject, DispatchWorkSubject and generic utilities for Subjects via Subjects methods.
hu.akarnokd.rxjava3.util - package hu.akarnokd.rxjava3.util
Utility classes and methods supporting the other utilities in this library.

I

ifThen(BooleanSupplier, CompletableSource, Completable) - Static method in class hu.akarnokd.rxjava3.expr.StatementCompletable
Return a Completable that emits the emissions from one specified Completable if a condition evaluates to true, or from another specified Completable otherwise.
ifThen(BooleanSupplier, Publisher<? extends R>) - Static method in class hu.akarnokd.rxjava3.expr.StatementFlowable
Return an Flowable that emits the emissions from a specified Flowable if a condition evaluates to true, otherwise return an empty Flowable.
ifThen(BooleanSupplier, Publisher<? extends R>, Scheduler) - Static method in class hu.akarnokd.rxjava3.expr.StatementFlowable
Return an Flowable that emits the emissions from a specified Flowable if a condition evaluates to true, otherwise return an empty Flowable that runs on a specified Scheduler.
ifThen(BooleanSupplier, Publisher<? extends R>, Flowable<? extends R>) - Static method in class hu.akarnokd.rxjava3.expr.StatementFlowable
Return an Flowable that emits the emissions from one specified Flowable if a condition evaluates to true, or from another specified Flowable otherwise.
ifThen(BooleanSupplier, MaybeSource<? extends R>) - Static method in class hu.akarnokd.rxjava3.expr.StatementMaybe
Return a Maybe that emits the emissions from a specified Maybe if a condition evaluates to true, otherwise return an empty Maybe.
ifThen(BooleanSupplier, MaybeSource<? extends R>, Scheduler) - Static method in class hu.akarnokd.rxjava3.expr.StatementMaybe
Return a Maybe that emits the emissions from a specified Maybe if a condition evaluates to true, otherwise return an empty Maybe that runs on a specified Scheduler.
ifThen(BooleanSupplier, MaybeSource<? extends R>, Maybe<? extends R>) - Static method in class hu.akarnokd.rxjava3.expr.StatementMaybe
Return a Maybe that emits the emissions from one specified Maybe if a condition evaluates to true, or from another specified Maybe otherwise.
ifThen(BooleanSupplier, ObservableSource<? extends R>) - Static method in class hu.akarnokd.rxjava3.expr.StatementObservable
Return an Observable that emits the emissions from a specified Observable if a condition evaluates to true, otherwise return an empty Observable.
ifThen(BooleanSupplier, ObservableSource<? extends R>, Scheduler) - Static method in class hu.akarnokd.rxjava3.expr.StatementObservable
Return an Observable that emits the emissions from a specified Observable if a condition evaluates to true, otherwise return an empty Observable that runs on a specified Scheduler.
ifThen(BooleanSupplier, ObservableSource<? extends R>, Observable<? extends R>) - Static method in class hu.akarnokd.rxjava3.expr.StatementObservable
Return an Observable that emits the emissions from one specified Observable if a condition evaluates to true, or from another specified Observable otherwise.
ifThen(BooleanSupplier, SingleSource<? extends R>, Single<? extends R>) - Static method in class hu.akarnokd.rxjava3.expr.StatementSingle
Return a Single that emits the emissions from one specified Single if a condition evaluates to true, or from another specified Single otherwise.
ignoreElement() - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Ignore the element of this Perhaps.
ignoreElement() - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Ignore the solo value of this Solo and only signal the terminal events.
indexOf(Predicate<? super T>) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Returns the first index of an element that matches a predicate or -1L if no elements match.
indexOf(Predicate<? super T>) - Static method in class hu.akarnokd.rxjava3.operators.ObservableTransformers
Returns the first index of an element that matches a predicate or -1L if no elements match.
innerComplete(InnerQueuedSubscriber<T>) - Method in class hu.akarnokd.rxjava3.operators.BasicMergeSubscription
 
innerError(InnerQueuedSubscriber<T>, Throwable) - Method in class hu.akarnokd.rxjava3.operators.BasicMergeSubscription
 
innerNext(InnerQueuedSubscriber<T>, T) - Method in class hu.akarnokd.rxjava3.operators.BasicMergeSubscription
 
instance() - Static method in enum hu.akarnokd.rxjava3.util.BiFunctionSecondIdentity
Returns a correctly typed instance of the enum's singleton instance.
instance() - Static method in enum hu.akarnokd.rxjava3.util.SelfComparator
 
intervalBackpressure(long, TimeUnit) - Static method in class hu.akarnokd.rxjava3.operators.Flowables
Periodically tries to emit an ever increasing long value or buffers (efficiently) such emissions until the downstream requests.
intervalBackpressure(long, TimeUnit, Scheduler) - Static method in class hu.akarnokd.rxjava3.operators.Flowables
Periodically tries to emit an ever increasing long value or buffers (efficiently) such emissions until the downstream requests.
intervalBackpressure(long, long, TimeUnit) - Static method in class hu.akarnokd.rxjava3.operators.Flowables
Periodically tries to emit an ever increasing long value or buffers (efficiently) such emissions until the downstream requests.
intervalBackpressure(long, long, TimeUnit, Scheduler) - Static method in class hu.akarnokd.rxjava3.operators.Flowables
Periodically tries to emit an ever increasing long value or buffers (efficiently) such emissions until the downstream requests.
isCancelled() - Method in interface hu.akarnokd.rxjava3.operators.FlowableAsyncEmitter
Returns true if the associated flow has been cancelled.
isCancelled() - Method in interface hu.akarnokd.rxjava3.operators.PartialCollectEmitter
The downstream requested cancellation.
isComplete() - Method in interface hu.akarnokd.rxjava3.operators.PartialCollectEmitter
The upstream completed sending new items.
isDisposed() - Method in class hu.akarnokd.rxjava3.processors.DispatchWorkProcessor
 
isDisposed() - Method in class hu.akarnokd.rxjava3.subjects.DispatchWorkSubject
 
isDisposed() - Method in class hu.akarnokd.rxjava3.subjects.UnicastWorkSubject
 
isEmpty() - Method in class hu.akarnokd.rxjava3.util.SpmcLinkedArrayQueue
 
isEmpty() - Method in class hu.akarnokd.rxjava3.util.SpscOneQueue
 
isEnabled() - Static method in class hu.akarnokd.rxjava3.debug.validator.RxJavaProtocolValidator
Returns true if the validation hooks have been installed.
isEnabled() - Static method in class hu.akarnokd.rxjava3.functions.FunctionTagging
Returns true if the function tagging wrappers are enabled.

J

JoinObservable<T> - Class in hu.akarnokd.rxjava3.joins
Represents an observable that supports join operations.
just(T) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Returns a Perhaps that signals the given item.
just(T) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Returns a Solo that signals the given item and completes.
justThrowX(Throwable) - Static method in class hu.akarnokd.rxjava3.util.SneakyThrows
 

L

lift(Function<Subscriber<? super Void>, Subscriber<? super Void>>) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Transform the downstream's Subscriber into a Subscriber for the upstream via a function.
lift(Function<Subscriber<? super R>, Subscriber<? super T>>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Map the downstream Subscriber into an upstream Subscriber.
lift(Function<Subscriber<? super R>, Subscriber<? super T>>) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Map the downstream Subscriber into an upstream Subscriber.

M

map(Function<? super T, ? extends R>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Maps the value of this Perhaps into another value (of possibly different type).
map(Function<? super T, ? extends R>) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Maps the value of this Solo into another value via function.
mapAsync(Function<? super T, ? extends Publisher<? extends R>>) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Maps each upstream value into a single value provided by a generated Publisher for that input value to be emitted to downstream.
mapAsync(Function<? super T, ? extends Publisher<? extends R>>, int) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Maps each upstream value into a single value provided by a generated Publisher for that input value to be emitted to downstream.
mapAsync(Function<? super T, ? extends Publisher<? extends U>>, BiFunction<? super T, ? super U, ? extends R>) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Maps each upstream value into a single value provided by a generated Publisher for that input value and combines the original and generated single value into a final result item to be emitted to downstream.
mapAsync(Function<? super T, ? extends Publisher<? extends U>>, BiFunction<? super T, ? super U, ? extends R>, int) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Maps each upstream value into a single value provided by a generated Publisher for that input value and combines the original and generated single value into a final result item to be emitted to downstream.
mapAsync(Function<? super T, ? extends ObservableSource<? extends R>>) - Static method in class hu.akarnokd.rxjava3.operators.ObservableTransformers
Maps each upstream value into a single value provided by a generated ObservableSource for that input value, which is then emitted to the downstream.
mapAsync(Function<? super T, ? extends ObservableSource<? extends R>>, int) - Static method in class hu.akarnokd.rxjava3.operators.ObservableTransformers
Maps each upstream value into a single value provided by a generated ObservableSource for that input value, which is then emitted to the downstream.
mapAsync(Function<? super T, ? extends ObservableSource<? extends U>>, BiFunction<? super T, ? super U, ? extends R>) - Static method in class hu.akarnokd.rxjava3.operators.ObservableTransformers
Maps each upstream value into a single value provided by a generated ObservableSource for that input value and combines the original and generated single value into a final result item to be emitted to downstream.
mapAsync(Function<? super T, ? extends ObservableSource<? extends U>>, BiFunction<? super T, ? super U, ? extends R>, int) - Static method in class hu.akarnokd.rxjava3.operators.ObservableTransformers
Maps each upstream value into a single value provided by a generated ObservableSource for that input value and combines the original and generated single value into a final result item to be emitted to downstream.
mapError(Function<? super Throwable, ? extends Throwable>) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Maps the upstream error into another Throwable via a function.
mapError(Function<? super Throwable, ? extends Throwable>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Maps the error from upstream into another Throwable error.
mapError(Function<? super Throwable, ? extends Throwable>) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Maps the Throwable error of this Solo into another Throwable error type.
mapFilter(BiConsumer<? super T, ? super BasicEmitter<R>>) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Allows mapping or filtering an upstream value through an emitter.
MathFlowable - Class in hu.akarnokd.rxjava3.math
Utility methods to work with numerical Flowable sources: sum, min, max and average.
MathObservable - Class in hu.akarnokd.rxjava3.math
Utility methods to work with numerical Observable sources: sum, min, max and average.
max(Publisher<T>) - Static method in class hu.akarnokd.rxjava3.math.MathFlowable
 
max(Publisher<T>, Comparator<? super T>) - Static method in class hu.akarnokd.rxjava3.math.MathFlowable
 
max(ObservableSource<T>) - Static method in class hu.akarnokd.rxjava3.math.MathObservable
 
max(ObservableSource<T>, Comparator<? super T>) - Static method in class hu.akarnokd.rxjava3.math.MathObservable
 
MaybeConsumers - Class in hu.akarnokd.rxjava3.consumers
Utility methods for creating and using consumers Maybes.
Maybes - Class in hu.akarnokd.rxjava3.operators
Additional operators in the form of MaybeConverters, use Maybe.to(MaybeConverter) to apply the operators to an existing sequence.
MaybeTransformers - Class in hu.akarnokd.rxjava3.operators
Additional operators in the form of MaybeTransformer, use Maybe.compose(MaybeTransformer) to apply the operators to an existing sequence.
merge(Iterable<? extends Nono>) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Runs all Nono sources at once and completes once all of them complete.
merge(Iterable<? extends Nono>, int) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Runs the maximum number of Nono sources at once and completes when all source Nono complete.
merge(Publisher<? extends Nono>) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Runs all Nono sources emitted by the Publisher at once and completes once all of them complete.
merge(Publisher<? extends Nono>, int) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Runs the maximum number of Nono sources emitted by the Publisher at once and completes when all source Nono complete.
merge(Iterable<? extends Perhaps<? extends T>>) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Merge the values in arbitrary order from a sequence of Perhaps sources.
merge(Iterable<? extends Perhaps<? extends T>>, int) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Merge the values in arbitrary order from a sequence of Perhaps sources.
merge(Publisher<? extends Perhaps<? extends T>>) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Merge the values in arbitrary order from a sequence of Perhaps sources.
merge(Publisher<? extends Perhaps<? extends T>>, int) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Merge the values in arbitrary order from a sequence of Perhaps sources.
merge(Iterable<? extends Solo<? extends T>>) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Merge the values in arbitrary order from a sequence of Solo sources.
merge(Iterable<? extends Solo<? extends T>>, int) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Merge the values in arbitrary order from a sequence of Solo sources.
merge(Publisher<? extends Solo<? extends T>>) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Merge the values in arbitrary order from a sequence of Solo sources.
merge(Publisher<? extends Solo<? extends T>>, int) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Merge the values in arbitrary order from a sequence of Solo sources.
mergeArray(Nono...) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Runs all Nono sources at once and completes once all of them complete.
mergeArray(int, Nono...) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Runs the maximum number of Nono sources at once and completes when all source Nono complete.
mergeArray(Perhaps<? extends T>...) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Merge the values in arbitrary order from a sequence of Perhaps sources.
mergeArray(int, Perhaps<? extends T>...) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Merge the values in arbitrary order from a sequence of Perhaps sources.
mergeArray(Solo<? extends T>...) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Merge the values in arbitrary order from a sequence of Solo sources.
mergeArray(int, Solo<? extends T>...) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Merge the values in arbitrary order from a sequence of Solo sources.
mergeArrayDelayError(Nono...) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Runs all Nono sources at once and terminates once all of them terminate, delaying errors in the process.
mergeArrayDelayError(int, Nono...) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Runs the maximum number of Nono sources at once and terminates when all source Nono terminate, delaying errors in the process.
mergeArrayDelayError(Perhaps<? extends T>...) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Merge the values in arbitrary order from a sequence of Perhaps sources, delaying errors till all sources terminate.
mergeArrayDelayError(int, Perhaps<? extends T>...) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Merge the values in arbitrary order from a sequence of Perhaps sources, delaying errors till all sources terminate.
mergeArrayDelayError(Solo<? extends T>...) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Merge the values in arbitrary order from a sequence of Solo sources, delaying errors till all sources terminate.
mergeArrayDelayError(int, Solo<? extends T>...) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Merge the values in arbitrary order from a sequence of Solo sources, delaying errors till all sources terminate.
mergeDelayError(Iterable<? extends Nono>) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Runs all Nono sources at once and terminates once all of them terminate, delaying errors in the process.
mergeDelayError(Iterable<? extends Nono>, int) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Runs the maximum number of Nono sources at once and terminates when all source Nono terminate, delaying errors in the process.
mergeDelayError(Publisher<? extends Nono>) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Runs all Nono sources emitted by the Publisher at once and terminates once all of them terminate, delaying errors in the process.
mergeDelayError(Publisher<? extends Nono>, int) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Runs the maximum number of Nono sources emitted by the Publisher at once and terminates when all source Nono terminate, delaying errors in the process.
mergeDelayError(Iterable<? extends Perhaps<? extends T>>) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Merge the values in arbitrary order from a sequence of Perhaps sources, delaying errors till all sources terminate.
mergeDelayError(Iterable<? extends Perhaps<? extends T>>, int) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Merge the values in arbitrary order from a sequence of Perhaps sources, delaying errors till all sources terminate.
mergeDelayError(Publisher<? extends Perhaps<? extends T>>) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Merge the values in arbitrary order from a sequence of Perhaps sources, delaying errors till all sources terminate.
mergeDelayError(Publisher<? extends Perhaps<? extends T>>, int) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Merge the values in arbitrary order from a sequence of Perhaps sources, delaying errors till all sources terminate.
mergeDelayError(Iterable<? extends Solo<? extends T>>) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Merge the values in arbitrary order from a sequence of Solo sources, delaying errors till all sources terminate.
mergeDelayError(Iterable<? extends Solo<? extends T>>, int) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Merge the values in arbitrary order from a sequence of Solo sources, delaying errors till all sources terminate.
mergeDelayError(Publisher<? extends Solo<? extends T>>) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Merge the values in arbitrary order from a sequence of Solo sources, delaying errors till all sources terminate.
mergeDelayError(Publisher<? extends Solo<? extends T>>, int) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Merge the values in arbitrary order from a sequence of Solo sources, delaying errors till all sources terminate.
mergeWith(Publisher<? extends T>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Merges this Perhaps with another Publisher and emits all their values.
mergeWith(Solo<T>) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Merges the values of this Solo and the other Solo into a Flowable sequence.
min(Publisher<T>) - Static method in class hu.akarnokd.rxjava3.math.MathFlowable
 
min(Publisher<T>, Comparator<? super T>) - Static method in class hu.akarnokd.rxjava3.math.MathFlowable
 
min(ObservableSource<T>) - Static method in class hu.akarnokd.rxjava3.math.MathObservable
 
min(ObservableSource<T>, Comparator<? super T>) - Static method in class hu.akarnokd.rxjava3.math.MathObservable
 
MultiHandlerManager<H> - Class in hu.akarnokd.rxjava3.debug.multihook
Manages an array of handlers.
MultiHandlerManager() - Constructor for class hu.akarnokd.rxjava3.debug.multihook.MultiHandlerManager
Constructs an empty handler manager.
MultipleOnSubscribeCallsException - Exception in hu.akarnokd.rxjava3.debug.validator
Indicates there were multiple onSubscribe calls.
MultipleOnSubscribeCallsException() - Constructor for exception hu.akarnokd.rxjava3.debug.validator.MultipleOnSubscribeCallsException
 
MultipleTerminationsException - Exception in hu.akarnokd.rxjava3.debug.validator
Indicates there were multiple onError or onComplete calls.
MultipleTerminationsException() - Constructor for exception hu.akarnokd.rxjava3.debug.validator.MultipleTerminationsException
 
MultipleTerminationsException(Throwable) - Constructor for exception hu.akarnokd.rxjava3.debug.validator.MultipleTerminationsException
 

N

never() - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Returns a Nono that never terminates.
never() - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Returns a Perhaps that never signals any item or terminal event.
never() - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Returns a Solo that never signals an item or terminal event.
next(R) - Method in interface hu.akarnokd.rxjava3.operators.PartialCollectEmitter
Signal the next output item.
Nono - Class in hu.akarnokd.rxjava3.basetypes
Represents the base reactive class with fluent API for Publisher-based, no-item just onError or onComplete source.
Nono() - Constructor for class hu.akarnokd.rxjava3.basetypes.Nono
 
NonoProcessor - Class in hu.akarnokd.rxjava3.basetypes
A hot Nono that signals the terminal event to Subscribers.
now(TimeUnit) - Method in class hu.akarnokd.rxjava3.schedulers.SharedScheduler
 
NullOnErrorParameterException - Exception in hu.akarnokd.rxjava3.debug.validator
Indicates the onError was called with a null Throwable.
NullOnErrorParameterException() - Constructor for exception hu.akarnokd.rxjava3.debug.validator.NullOnErrorParameterException
 
NullOnNextParameterException - Exception in hu.akarnokd.rxjava3.debug.validator
Indicates the onNext was called with a null value.
NullOnNextParameterException() - Constructor for exception hu.akarnokd.rxjava3.debug.validator.NullOnNextParameterException
 
NullOnSubscribeParameterException - Exception in hu.akarnokd.rxjava3.debug.validator
Indicates the onSubscribe was called with a null Disposable or Subscription.
NullOnSubscribeParameterException() - Constructor for exception hu.akarnokd.rxjava3.debug.validator.NullOnSubscribeParameterException
 
NullOnSuccessParameterException - Exception in hu.akarnokd.rxjava3.debug.validator
Indicates the onSuccess was called with a null value.
NullOnSuccessParameterException() - Constructor for exception hu.akarnokd.rxjava3.debug.validator.NullOnSuccessParameterException
 

O

ObservableAverageDouble - Class in hu.akarnokd.rxjava3.math
 
ObservableAverageDouble(ObservableSource<Number>) - Constructor for class hu.akarnokd.rxjava3.math.ObservableAverageDouble
 
ObservableAverageFloat - Class in hu.akarnokd.rxjava3.math
 
ObservableAverageFloat(ObservableSource<Number>) - Constructor for class hu.akarnokd.rxjava3.math.ObservableAverageFloat
 
ObservableConsumers - Class in hu.akarnokd.rxjava3.consumers
Utility methods for creating and using consumers Observables.
Observables - Class in hu.akarnokd.rxjava3.operators
Utility class to create Observable sources.
ObservableSumDouble - Class in hu.akarnokd.rxjava3.math
 
ObservableSumDouble(ObservableSource<Double>) - Constructor for class hu.akarnokd.rxjava3.math.ObservableSumDouble
 
ObservableSumFloat - Class in hu.akarnokd.rxjava3.math
 
ObservableSumFloat(ObservableSource<Float>) - Constructor for class hu.akarnokd.rxjava3.math.ObservableSumFloat
 
ObservableSumLong - Class in hu.akarnokd.rxjava3.math
 
ObservableSumLong(ObservableSource<Long>) - Constructor for class hu.akarnokd.rxjava3.math.ObservableSumLong
 
ObservableTransformers - Class in hu.akarnokd.rxjava3.operators
Additional operators in the form of ObservableTransformer, use Observable.compose(ObservableTransformer) to apply the operators to an existing sequence.
observeOn(Scheduler) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Observes the onError and onComplete events on the specified Scheduler.
observeOn(Scheduler) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Observe the events of this Perhaps on the specified scheduler.
observeOn(Scheduler) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Returns a Solo that delivers the onNext, onError and onComplete signals from this Solo on the specified scheduler.
observeOnDrop(Scheduler) - Static method in class hu.akarnokd.rxjava3.operators.ObservableTransformers
Schedules the event emission on a Scheduler and drops upstream values while the onNext with the current item is executing on that scheduler.
observeOnLatest(Scheduler) - Static method in class hu.akarnokd.rxjava3.operators.ObservableTransformers
Schedules the event emission on a Scheduler and keeps the latest upstream item while the downstream's onNext is executing so that it will resume with that latest value.
offer(T) - Method in class hu.akarnokd.rxjava3.util.SpmcLinkedArrayQueue
 
offer(T, T) - Method in class hu.akarnokd.rxjava3.util.SpmcLinkedArrayQueue
 
offer(T) - Method in class hu.akarnokd.rxjava3.util.SpscOneQueue
 
offer(T, T) - Method in class hu.akarnokd.rxjava3.util.SpscOneQueue
 
onAssembly(Nono) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Optionally apply a function to the raw source and return a potentially modified Nono instance.
onAssembly(Perhaps<T>) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
 
onAssembly(Solo<T>) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
 
onBackpressureTimeout(long, TimeUnit) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Buffers the incoming values from upstream up to a maximum timeout if the downstream can't keep up.
onBackpressureTimeout(long, TimeUnit, Scheduler, Consumer<? super T>) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Buffers the incoming values from upstream up to a maximum size or timeout if the downstream can't keep up.
onBackpressureTimeout(long, TimeUnit, Scheduler) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Buffers the incoming values from upstream up to a maximum timeout if the downstream can't keep up, running on a custom scheduler.
onBackpressureTimeout(int, long, TimeUnit, Scheduler, Consumer<? super T>) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Buffers the incoming values from upstream up to a maximum size or timeout if the downstream can't keep up.
onComplete() - Method in class hu.akarnokd.rxjava3.basetypes.NonoProcessor
 
onComplete() - Method in class hu.akarnokd.rxjava3.basetypes.PerhapsProcessor
 
onComplete() - Method in class hu.akarnokd.rxjava3.basetypes.SoloProcessor
 
onComplete() - Method in class hu.akarnokd.rxjava3.processors.DispatchWorkProcessor
 
onComplete() - Method in class hu.akarnokd.rxjava3.subjects.DispatchWorkSubject
 
onComplete() - Method in class hu.akarnokd.rxjava3.subjects.UnicastWorkSubject
 
onError(Throwable) - Method in class hu.akarnokd.rxjava3.basetypes.NonoProcessor
 
onError(Throwable) - Method in class hu.akarnokd.rxjava3.basetypes.PerhapsProcessor
 
onError(Throwable) - Method in class hu.akarnokd.rxjava3.basetypes.SoloProcessor
 
onError(Throwable) - Method in class hu.akarnokd.rxjava3.processors.DispatchWorkProcessor
 
onError(Throwable) - Method in class hu.akarnokd.rxjava3.subjects.DispatchWorkSubject
 
onError(Throwable) - Method in class hu.akarnokd.rxjava3.subjects.UnicastWorkSubject
 
onErrorComplete() - Method in class hu.akarnokd.rxjava3.basetypes.Nono
If this Nono signals an error, signal an onComplete instead.
onErrorComplete() - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Completes in case the upstream signals an error.
onErrorFrom(Observer<T>) - Static method in class hu.akarnokd.rxjava3.joins.Plan
Extracts a method reference to the Observer's onError method in the form of an Consumer.
onErrorResumeNext(Function<? super Throwable, ? extends Nono>) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
If this Nono signals an error, subscribe to the fallback Nono returned by the error handler function.
onErrorResumeNext(Function<? super Throwable, ? extends Perhaps<? extends T>>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
If the upstream signals an error, apply the given function to that Throwable error and resume with the returned Perhaps.
onErrorResumeNext(Function<? super Throwable, ? extends Solo<T>>) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
If the upstream signals an error, call a function and subscribe to the Solo it returns.
onErrorResumeWith(Perhaps<? extends T>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
If the upstream signals an error, switch to the given fallback Perhaps.
onErrorResumeWith(Solo<T>) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
If the upstream signals an error, switch over to the next Solo and emits its signal instead.
onErrorReturnItem(T) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
If the upstream signals an error, it is replaced by a signal of the given item and normal completion.
onErrorReturnItem(T) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
If the upstream signals an error, signal an item instead.
onNext(Void) - Method in class hu.akarnokd.rxjava3.basetypes.NonoProcessor
 
onNext(T) - Method in class hu.akarnokd.rxjava3.basetypes.PerhapsProcessor
 
onNext(T) - Method in class hu.akarnokd.rxjava3.basetypes.SoloProcessor
 
onNext(T) - Method in class hu.akarnokd.rxjava3.processors.DispatchWorkProcessor
 
onNext(T) - Method in class hu.akarnokd.rxjava3.subjects.DispatchWorkSubject
 
onNext(T) - Method in class hu.akarnokd.rxjava3.subjects.UnicastWorkSubject
 
OnNextAfterTerminationException - Exception in hu.akarnokd.rxjava3.debug.validator
The onNext was invoked after an onError or onComplete call.
OnNextAfterTerminationException() - Constructor for exception hu.akarnokd.rxjava3.debug.validator.OnNextAfterTerminationException
 
onNothing() - Method in interface hu.akarnokd.rxjava3.operators.FlowableAsyncEmitter
The async logic may call this method to indicate the async API invocation didn't produce any items but it hasn't ended either, therefore, the generator can perform another API invocation immediately.
OnScheduleMultiHandlerManager - Class in hu.akarnokd.rxjava3.debug.multihook
Handles the OnSchedule hooks.
OnScheduleMultiHandlerManager() - Constructor for class hu.akarnokd.rxjava3.debug.multihook.OnScheduleMultiHandlerManager
 
onSubscribe(Subscription) - Method in class hu.akarnokd.rxjava3.basetypes.NonoProcessor
 
onSubscribe(Subscription) - Method in class hu.akarnokd.rxjava3.basetypes.PerhapsProcessor
 
onSubscribe(Subscription) - Method in class hu.akarnokd.rxjava3.basetypes.SoloProcessor
 
onSubscribe(Subscription) - Method in class hu.akarnokd.rxjava3.processors.DispatchWorkProcessor
 
onSubscribe(Disposable) - Method in class hu.akarnokd.rxjava3.subjects.DispatchWorkSubject
 
onSubscribe(Disposable) - Method in class hu.akarnokd.rxjava3.subjects.UnicastWorkSubject
 
OnSubscribeNotCalledException - Exception in hu.akarnokd.rxjava3.debug.validator
The onSubscribe was not called before calling onNext, onSuccess, onError or onComplete.
OnSubscribeNotCalledException() - Constructor for exception hu.akarnokd.rxjava3.debug.validator.OnSubscribeNotCalledException
 
OnSubscribeNotCalledException(Throwable) - Constructor for exception hu.akarnokd.rxjava3.debug.validator.OnSubscribeNotCalledException
 
OnSuccessAfterTerminationException - Exception in hu.akarnokd.rxjava3.debug.validator
The onSuccess was invoked after an onError or onComplete call.
OnSuccessAfterTerminationException() - Constructor for exception hu.akarnokd.rxjava3.debug.validator.OnSuccessAfterTerminationException
 
orderedMerge(Publisher<T>...) - Static method in class hu.akarnokd.rxjava3.operators.Flowables
Merges the source Publishers in an ordered fashion picking the smallest of the available value from them (determined by their natural order).
orderedMerge(boolean, Publisher<T>...) - Static method in class hu.akarnokd.rxjava3.operators.Flowables
Merges the source Publishers in an ordered fashion picking the smallest of the available value from them (determined by their natural order) and allows delaying any error they may signal.
orderedMerge(boolean, int, Publisher<T>...) - Static method in class hu.akarnokd.rxjava3.operators.Flowables
Merges the source Publishers in an ordered fashion picking the smallest of the available value from them (determined by their natural order), allows delaying any error they may signal and sets the prefetch amount when requesting from these Publishers.
orderedMerge(Comparator<? super T>, Publisher<T>...) - Static method in class hu.akarnokd.rxjava3.operators.Flowables
Merges the source Publishers in an ordered fashion picking the smallest of the available value from them (determined by the Comparator).
orderedMerge(Comparator<? super T>, boolean, Publisher<T>...) - Static method in class hu.akarnokd.rxjava3.operators.Flowables
Merges the source Publishers in an ordered fashion picking the smallest of the available value from them (determined by the Comparator) and allows delaying any error they may signal.
orderedMerge(Comparator<? super T>, boolean, int, Publisher<T>...) - Static method in class hu.akarnokd.rxjava3.operators.Flowables
Merges the source Publishers in an ordered fashion picking the smallest of the available value from them (determined by the Comparator), allows delaying any error they may signal and sets the prefetch amount when requesting from these Publishers.
orderedMerge(Iterable<? extends Publisher<T>>, Comparator<? super T>) - Static method in class hu.akarnokd.rxjava3.operators.Flowables
Merges the source Publishers in an ordered fashion picking the smallest of the available value from them (determined by the Comparator).
orderedMerge(Iterable<? extends Publisher<T>>, Comparator<? super T>, boolean) - Static method in class hu.akarnokd.rxjava3.operators.Flowables
Merges the source Publishers in an ordered fashion picking the smallest of the available value from them (determined by the Comparator) and allows delaying any error they may signal.
orderedMerge(Iterable<? extends Publisher<T>>, Comparator<? super T>, boolean, int) - Static method in class hu.akarnokd.rxjava3.operators.Flowables
Merges the source Publishers in an ordered fashion picking the smallest of the available value from them (determined by the Comparator), allows delaying any error they may signal and sets the prefetch amount when requesting from these Publishers.
orderedMerge(Iterable<? extends Publisher<T>>) - Static method in class hu.akarnokd.rxjava3.operators.Flowables
Merges the source Publishers in an ordered fashion picking the smallest of the available value from them (determined by their natural order).
orderedMerge(Iterable<? extends Publisher<T>>, boolean) - Static method in class hu.akarnokd.rxjava3.operators.Flowables
Merges the source Publishers in an ordered fashion picking the smallest of the available value from them (determined by their natural order) and allows delaying any error they may signal.
orderedMerge(Iterable<? extends Publisher<T>>, boolean, int) - Static method in class hu.akarnokd.rxjava3.operators.Flowables
Merges the source Publishers in an ordered fashion picking the smallest of the available value from them (determined by their natural order), allows delaying any error they may signal and sets the prefetch amount when requesting from these Publishers.
orderedMerge(ParallelFlowable<T>) - Static method in class hu.akarnokd.rxjava3.parallel.ParallelTransformers
Merges the source ParallelFlowable rails in an ordered fashion picking the smallest of the available value from them (determined by their natural order).
orderedMerge(ParallelFlowable<T>, boolean) - Static method in class hu.akarnokd.rxjava3.parallel.ParallelTransformers
Merges the source ParallelFlowable rails in an ordered fashion picking the smallest of the available value from them (determined by their natural order) and allows delaying any error they may signal.
orderedMerge(ParallelFlowable<T>, boolean, int) - Static method in class hu.akarnokd.rxjava3.parallel.ParallelTransformers
Merges the source ParallelFlowable rails in an ordered fashion picking the smallest of the available value from them (determined by their natural order), allows delaying any error they may signal and sets the prefetch amount when requesting from these Publishers.
orderedMerge(ParallelFlowable<T>, Comparator<? super T>) - Static method in class hu.akarnokd.rxjava3.parallel.ParallelTransformers
Merges the source ParallelFlowable rails in an ordered fashion picking the smallest of the available value from them (determined by the Comparator).
orderedMerge(ParallelFlowable<T>, Comparator<? super T>, boolean) - Static method in class hu.akarnokd.rxjava3.parallel.ParallelTransformers
Merges the source ParallelFlowable rails in an ordered fashion picking the smallest of the available value from them (determined by the Comparator) and allows delaying any error they may signal.
orderedMerge(ParallelFlowable<T>, Comparator<? super T>, boolean, int) - Static method in class hu.akarnokd.rxjava3.parallel.ParallelTransformers
Merges the source ParallelFlowable rails in an ordered fashion picking the smallest of the available value from them (determined by the Comparator), allows delaying any error they may signal and sets the prefetch amount when requesting from these Publishers.

P

ParallelScheduler - Class in hu.akarnokd.rxjava3.schedulers
Scheduler with a configurable fixed amount of thread-pools.
ParallelScheduler() - Constructor for class hu.akarnokd.rxjava3.schedulers.ParallelScheduler
 
ParallelScheduler(String) - Constructor for class hu.akarnokd.rxjava3.schedulers.ParallelScheduler
 
ParallelScheduler(int) - Constructor for class hu.akarnokd.rxjava3.schedulers.ParallelScheduler
 
ParallelScheduler(int, boolean) - Constructor for class hu.akarnokd.rxjava3.schedulers.ParallelScheduler
 
ParallelScheduler(int, boolean, int) - Constructor for class hu.akarnokd.rxjava3.schedulers.ParallelScheduler
 
ParallelScheduler(int, boolean, int, String) - Constructor for class hu.akarnokd.rxjava3.schedulers.ParallelScheduler
 
ParallelScheduler(int, ThreadFactory) - Constructor for class hu.akarnokd.rxjava3.schedulers.ParallelScheduler
 
ParallelScheduler(int, ThreadFactory, boolean) - Constructor for class hu.akarnokd.rxjava3.schedulers.ParallelScheduler
 
ParallelTransformers - Class in hu.akarnokd.rxjava3.parallel
Transformers for RxJava 2 ParallelFlowable sequences.
partialCollect(Consumer<? super PartialCollectEmitter<T, I, A, R>>, Consumer<? super T>, int) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Allows converting upstream items into output objects where an upstream item may represent such output objects partially or may represent more than one output object.
PartialCollectEmitter<T,I,A,R> - Interface in hu.akarnokd.rxjava3.operators
Provides callbacks and methods to support the partial collect operator: access to cached elements, save and retrieve an input index and accumulator and produce the output instance.
Pattern1<T1> - Class in hu.akarnokd.rxjava3.joins
Represents a join pattern over Observable sequences.
Pattern1(Observable<T1>) - Constructor for class hu.akarnokd.rxjava3.joins.Pattern1
 
Pattern2<T1,T2> - Class in hu.akarnokd.rxjava3.joins
Represents a join pattern over observable sequences.
Pattern2(Observable<T1>, Observable<T2>) - Constructor for class hu.akarnokd.rxjava3.joins.Pattern2
 
Pattern3<T1,T2,T3> - Class in hu.akarnokd.rxjava3.joins
Represents a join pattern over observable sequences.
Pattern3(Observable<T1>, Observable<T2>, Observable<T3>) - Constructor for class hu.akarnokd.rxjava3.joins.Pattern3
 
Pattern4<T1,T2,T3,T4> - Class in hu.akarnokd.rxjava3.joins
Represents a join pattern over observable sequences.
Pattern4(Observable<T1>, Observable<T2>, Observable<T3>, Observable<T4>) - Constructor for class hu.akarnokd.rxjava3.joins.Pattern4
 
Pattern5<T1,T2,T3,T4,T5> - Class in hu.akarnokd.rxjava3.joins
Represents a join pattern over observable sequences.
Pattern5(Observable<T1>, Observable<T2>, Observable<T3>, Observable<T4>, Observable<T5>) - Constructor for class hu.akarnokd.rxjava3.joins.Pattern5
 
Pattern6<T1,T2,T3,T4,T5,T6> - Class in hu.akarnokd.rxjava3.joins
Represents a join pattern over observable sequences.
Pattern6(Observable<T1>, Observable<T2>, Observable<T3>, Observable<T4>, Observable<T5>, Observable<T6>) - Constructor for class hu.akarnokd.rxjava3.joins.Pattern6
 
Pattern7<T1,T2,T3,T4,T5,T6,T7> - Class in hu.akarnokd.rxjava3.joins
Represents a join pattern over observable sequences.
Pattern7(Observable<T1>, Observable<T2>, Observable<T3>, Observable<T4>, Observable<T5>, Observable<T6>, Observable<T7>) - Constructor for class hu.akarnokd.rxjava3.joins.Pattern7
 
Pattern8<T1,T2,T3,T4,T5,T6,T7,T8> - Class in hu.akarnokd.rxjava3.joins
Represents a join pattern over observable sequences.
Pattern8(Observable<T1>, Observable<T2>, Observable<T3>, Observable<T4>, Observable<T5>, Observable<T6>, Observable<T7>, Observable<T8>) - Constructor for class hu.akarnokd.rxjava3.joins.Pattern8
 
Pattern9<T1,T2,T3,T4,T5,T6,T7,T8,T9> - Class in hu.akarnokd.rxjava3.joins
Represents a join pattern over observable sequences.
Pattern9(Observable<T1>, Observable<T2>, Observable<T3>, Observable<T4>, Observable<T5>, Observable<T6>, Observable<T7>, Observable<T8>, Observable<T9>) - Constructor for class hu.akarnokd.rxjava3.joins.Pattern9
 
PatternN - Class in hu.akarnokd.rxjava3.joins
Represents a join pattern over observable sequences.
PatternN(List<Observable<? extends Object>>) - Constructor for class hu.akarnokd.rxjava3.joins.PatternN
 
PatternN(List<Observable<? extends Object>>, Observable<? extends Object>) - Constructor for class hu.akarnokd.rxjava3.joins.PatternN
 
Perhaps<T> - Class in hu.akarnokd.rxjava3.basetypes
A 0-1-error base reactive type, similar to Maybe, implementing the Reactive-Streams Publisher interface.
Perhaps() - Constructor for class hu.akarnokd.rxjava3.basetypes.Perhaps
 
PerhapsProcessor<T> - Class in hu.akarnokd.rxjava3.basetypes
A Processor based on the Perhaps type that emits an onNext+onComplete, only onComplete or an onError.
PlainBiConsumer<T1,T2> - Interface in hu.akarnokd.rxjava3.functions
A BiConsumer with suppressed exception on its PlainBiConsumer.accept(Object, Object) method.
PlainBiFunction<T1,T2,R> - Interface in hu.akarnokd.rxjava3.functions
A BiFunction with suppressed exception on its PlainBiFunction.apply(Object, Object) method.
PlainConsumer<T> - Interface in hu.akarnokd.rxjava3.functions
A Consumer with suppressed exception on its PlainConsumer.accept(Object) method.
PlainFunction<T,R> - Interface in hu.akarnokd.rxjava3.functions
A Function with suppressed exception on its PlainFunction.apply(Object) method.
PlainFunction3<T1,T2,T3,R> - Interface in hu.akarnokd.rxjava3.functions
A Function3 with suppressed exception on its PlainFunction3.apply(Object, Object, Object) method.
PlainFunction4<T1,T2,T3,T4,R> - Interface in hu.akarnokd.rxjava3.functions
A Function4 with suppressed exception on its PlainFunction4.apply(Object, Object, Object, Object) method.
PlainFunction5<T1,T2,T3,T4,T5,R> - Interface in hu.akarnokd.rxjava3.functions
PlainFunction6<T1,T2,T3,T4,T5,T6,R> - Interface in hu.akarnokd.rxjava3.functions
PlainFunction7<T1,T2,T3,T4,T5,T6,T7,R> - Interface in hu.akarnokd.rxjava3.functions
PlainFunction8<T1,T2,T3,T4,T5,T6,T7,T8,R> - Interface in hu.akarnokd.rxjava3.functions
PlainFunction9<T1,T2,T3,T4,T5,T6,T7,T8,T9,R> - Interface in hu.akarnokd.rxjava3.functions
Plan<R> - Class in hu.akarnokd.rxjava3.joins
Represents an execution plan for join patterns.
Plan() - Constructor for class hu.akarnokd.rxjava3.joins.Plan
 
poll() - Method in class hu.akarnokd.rxjava3.util.SpmcLinkedArrayQueue
 
poll() - Method in class hu.akarnokd.rxjava3.util.SpscOneQueue
 
ProtocolNonConformanceException - Exception in hu.akarnokd.rxjava3.debug.validator
Base exception type indicating a failure in conforming the Reactive-Streams or derived protocol.
ProtocolNonConformanceException() - Constructor for exception hu.akarnokd.rxjava3.debug.validator.ProtocolNonConformanceException
 
ProtocolNonConformanceException(String, Throwable) - Constructor for exception hu.akarnokd.rxjava3.debug.validator.ProtocolNonConformanceException
 
ProtocolNonConformanceException(String) - Constructor for exception hu.akarnokd.rxjava3.debug.validator.ProtocolNonConformanceException
 
ProtocolNonConformanceException(Throwable) - Constructor for exception hu.akarnokd.rxjava3.debug.validator.ProtocolNonConformanceException
 

R

refCount(FlowableProcessor<T>) - Static method in class hu.akarnokd.rxjava3.processors.FlowableProcessors
Wraps a FlowableProcessor and makes sure if all subscribers cancel their subscriptions, the upstream's Subscription gets cancelled as well.
refCount(Subject<T>) - Static method in class hu.akarnokd.rxjava3.subjects.Subjects
Wraps a Subject and makes sure if all observers dispose their disposables, the upstream's Disposable gets disposed as well.
register(H) - Method in class hu.akarnokd.rxjava3.debug.multihook.MultiHandlerManager
Registers the specified handler instance with this MultiHandlerManager.
repeat() - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Repeatedly run this Nono indefinitely.
repeat(long) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Repeatedly run this Nono at most the given number of times.
repeat(BooleanSupplier) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Repeat until the given BooleanSupplier returns true.
repeat() - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Repeats this Perhaps indefinitely.
repeat(long) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Repeats this Perhaps at most the given number of times.
repeat(BooleanSupplier) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Repeats this Perhaps until the given boolean supplier returns true when an repeat iteration of this Perhaps completes.
repeat() - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Repeats this Solo indefinitely.
repeat(long) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Repeats this Solo at most the given number of times.
repeat(BooleanSupplier) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Repeats this Solo until the given boolean supplier returns true when an repeat iteration of this Solo completes.
repeat(T) - Static method in class hu.akarnokd.rxjava3.operators.Flowables
Repeats a scalar value indefinitely.
repeatSupplier(Supplier<T>) - Static method in class hu.akarnokd.rxjava3.operators.Flowables
Repeatedly calls the given Supplier to produce items indefinitely.
repeatWhen(Function<? super Flowable<Object>, ? extends Publisher<?>>) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Repeat when the Publisher returned by the handler function signals a value or terminate accordingly.
repeatWhen(Function<? super Flowable<Object>, ? extends Publisher<?>>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Repeats this Perhaps when the Publisher returned by the handler function emits an item or terminates if this Publisher terminates.
repeatWhen(Function<? super Flowable<Object>, ? extends Publisher<?>>) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Repeats this Solo when the Publisher returned by the handler function emits an item or terminates if this Publisher terminates.
replaceCancellable(Cancellable) - Method in interface hu.akarnokd.rxjava3.operators.FlowableAsyncEmitter
Sets the current Cancellable resource to the provided one.
request(long) - Method in class hu.akarnokd.rxjava3.operators.BasicMergeSubscription
 
request(long) - Method in class hu.akarnokd.rxjava3.util.CompositeSubscription
 
requestObserveOn(Scheduler) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Requests items one-by-one from the upstream from the given Scheduler and emits those items received on the same Scheduler, allowing a more interleaved usage of the target Scheduler (aka "fair" use).
requestSample(long, TimeUnit, Scheduler) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Issues a request(1) to the upstream repeatedly after the given period time elapses (including the very first request(1)).
requestSample(long, long, TimeUnit, Scheduler) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Issues a request(1) to the upstream after an initial delay, then repeatedly by given period.
requestSample(Publisher<U>) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Issues a request(1) to the upstream when the other Publisher signals an onNext.
restore() - Method in interface hu.akarnokd.rxjava3.debug.SavedHooks
Restore the previous set of hooks.
retry() - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Repeatedly run this Nono indefinitely if it fails.
retry(long) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Repeatedly run this Nono at most the given number of times if it fails.
retry(Predicate<? super Throwable>) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Retry a failed Nono if the predicate return true.
retry() - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Retry this Perhaps indefinitely if it fails.
retry(long) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Retry this Perhaps at most the given number of times if it fails.
retry(Predicate<? super Throwable>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Retry this Perhaps if the predicate returns true for the latest failure Throwable.
retry() - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Retry this Solo indefinitely if it fails.
retry(long) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Retry this Solo at most the given number of times if it fails.
retry(Predicate<? super Throwable>) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Retry this Solo if the predicate returns true for the latest failure Throwable.
retryWhen(Function<? super Flowable<Throwable>, ? extends Publisher<?>>) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Retry this Nono when the Publisher returned by the handler function signals a normal item or terminate if the Publisher terminates.
retryWhen(Function<? super Flowable<Throwable>, ? extends Publisher<?>>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Retry this Perhaps if the Publisher returned by the handler signals an item in response to the failure Throwable.
retryWhen(Function<? super Flowable<Throwable>, ? extends Publisher<?>>) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Retry this solo if the Publisher returned by the handler signals an item in response to the failure Throwable.
runAsync(Scheduler, BiConsumer<? super Subscriber<? super T>, ? super Disposable>) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Runs the provided action on the given scheduler and allows propagation of multiple events to the observers of the returned DisposableFlowable.
runAsync(Scheduler, Processor<T, U>, BiConsumer<? super Subscriber<? super T>, ? super Disposable>) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Runs the provided action on the given scheduler and allows propagation of multiple events to the observers of the returned DisposableFlowable.
runAsync(Scheduler, BiConsumer<? super Observer<? super T>, ? super Disposable>) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Runs the provided action on the given scheduler and allows propagation of multiple events to the observers of the returned DisposableObservable.
runAsync(Scheduler, Subject<T>, BiConsumer<? super Observer<? super T>, ? super Disposable>) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Runs the provided action on the given scheduler and allows propagation of multiple events to the observers of the returned DisposableObservable.
RxJavaAssemblyException - Exception in hu.akarnokd.rxjava3.debug
Holds onto the assembly stacktrace.
RxJavaAssemblyException() - Constructor for exception hu.akarnokd.rxjava3.debug.RxJavaAssemblyException
 
RxJavaAssemblyTracking - Class in hu.akarnokd.rxjava3.debug
Utility class to enable and disable tracking of operator application (source.map().filter()) by capturing the current stacktrace (warning: very expensive!), have it in a debug-time accessible field (when walking the references in a debugger) and append it to exceptions passing by the regular onError.
RxJavaProtocolValidator - Class in hu.akarnokd.rxjava3.debug.validator
Installs assembly hooks that validate the Reactive-Streams and derived protocols are honored.

S

SavedHooks - Interface in hu.akarnokd.rxjava3.debug
Remembers the previous hooks overridden by the debug function and allows restoring them via the SavedHooks.restore() method call.
scheduleDirect(Runnable, long, TimeUnit) - Method in class hu.akarnokd.rxjava3.schedulers.BlockingScheduler
 
scheduleDirect(Runnable) - Method in class hu.akarnokd.rxjava3.schedulers.ParallelScheduler
 
scheduleDirect(Runnable, long, TimeUnit) - Method in class hu.akarnokd.rxjava3.schedulers.ParallelScheduler
 
scheduleDirect(Runnable) - Method in class hu.akarnokd.rxjava3.schedulers.SharedScheduler
 
scheduleDirect(Runnable, long, TimeUnit) - Method in class hu.akarnokd.rxjava3.schedulers.SharedScheduler
 
schedulePeriodicallyDirect(Runnable, long, long, TimeUnit) - Method in class hu.akarnokd.rxjava3.schedulers.ParallelScheduler
 
schedulePeriodicallyDirect(Runnable, long, long, TimeUnit) - Method in class hu.akarnokd.rxjava3.schedulers.SharedScheduler
 
SelfComparator - Enum in hu.akarnokd.rxjava3.util
Comparator that compares Comparables.
setAccumulator(A) - Method in interface hu.akarnokd.rxjava3.operators.PartialCollectEmitter
Sets an optional, user-defined accumulator that can be used to aggregate partial items from upstream.
setCancellable(Cancellable) - Method in interface hu.akarnokd.rxjava3.operators.FlowableAsyncEmitter
Sets the current Cancellable resource to the provided one and cancels the previous one if present.
setIndex(I) - Method in interface hu.akarnokd.rxjava3.operators.PartialCollectEmitter
Sets an optional, user-defined index that can be used as a read poitner into the very first upstream item.
setOnAssemblyHandler(Function<Nono, Nono>) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Sets the onAssembly handler.
setOnAssemblyHandler(Function<Perhaps<T>, Perhaps<T>>) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Set the onAssembly handler.
setOnAssemblyHandler(Function<Solo<T>, Solo<T>>) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Set the onAssembly handler.
setOnViolationHandler(PlainConsumer<ProtocolNonConformanceException>) - Static method in class hu.akarnokd.rxjava3.debug.validator.RxJavaProtocolValidator
Set a custom violation callback handler.
SharedScheduler - Class in hu.akarnokd.rxjava3.schedulers
A Scheduler implementation that uses one of the Workers from another Scheduler and shares the access to it through its own Workers.
SharedScheduler(Scheduler) - Constructor for class hu.akarnokd.rxjava3.schedulers.SharedScheduler
Constructs a SharedScheduler and asks for a Worker from the provided other Scheduler.
SharedScheduler(Scheduler.Worker) - Constructor for class hu.akarnokd.rxjava3.schedulers.SharedScheduler
Constructs a SharedScheduler and uses the Worker instance provided.
shutdown() - Method in class hu.akarnokd.rxjava3.schedulers.BlockingScheduler
 
shutdown() - Method in class hu.akarnokd.rxjava3.schedulers.ParallelScheduler
 
shutdown() - Method in class hu.akarnokd.rxjava3.schedulers.SharedScheduler
 
SimpleCallable<T> - Interface in hu.akarnokd.rxjava3.functions
A Callable with suppressed exception on its SimpleCallable.call() method.
SingleConsumers - Class in hu.akarnokd.rxjava3.consumers
Utility methods for creating and using consumers SingleObservers.
Singles - Class in hu.akarnokd.rxjava3.operators
Additional operators in the form of SingleConverters, use Single.to(SingleConverter) to apply the operators to an existing sequence.
SingleTransformers - Class in hu.akarnokd.rxjava3.operators
Additional operators in the form of SingleTransformer, use Single.compose(SingleTransformer) to apply the operators to an existing sequence.
size() - Method in interface hu.akarnokd.rxjava3.operators.PartialCollectEmitter
The number of items cached and accessible via PartialCollectEmitter.getItem(int).
SneakyThrows - Class in hu.akarnokd.rxjava3.util
Utility class to throw arbitrary Throwables.
Solo<T> - Class in hu.akarnokd.rxjava3.basetypes
Base class with fluent API for supporting a Publisher with exactly 1 element or an error.
Solo() - Constructor for class hu.akarnokd.rxjava3.basetypes.Solo
 
SoloProcessor<T> - Class in hu.akarnokd.rxjava3.basetypes
A Processor based on the Solo type that emits an onNext+onComplete or an onError.
spanout(long, TimeUnit) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Inserts a time delay between emissions from the upstream source.
spanout(long, TimeUnit, Scheduler) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Inserts a time delay between emissions from the upstream source.
spanout(long, long, TimeUnit) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Inserts a time delay between emissions from the upstream source, including an initial delay.
spanout(long, long, TimeUnit, Scheduler) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Inserts a time delay between emissions from the upstream source, including an initial delay.
spanout(long, TimeUnit, boolean) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Inserts a time delay between emissions from the upstream source, including an initial delay.
spanout(long, TimeUnit, Scheduler, boolean) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Inserts a time delay between emissions from the upstream source, including an initial delay.
spanout(long, long, TimeUnit, boolean) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Inserts a time delay between emissions from the upstream source, including an initial delay.
spanout(long, long, TimeUnit, Scheduler, boolean) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Inserts a time delay between emissions from the upstream source, including an initial delay.
split(Pattern) - Static method in class hu.akarnokd.rxjava3.string.StringFlowable
Splits the input sequence of strings based on a pattern even across subsequent elements if needed.
split(Pattern, int) - Static method in class hu.akarnokd.rxjava3.string.StringFlowable
Splits the input sequence of strings based on a pattern even across subsequent elements if needed.
split(String) - Static method in class hu.akarnokd.rxjava3.string.StringFlowable
Splits the input sequence of strings based on a pattern even across subsequent elements if needed.
split(String, int) - Static method in class hu.akarnokd.rxjava3.string.StringFlowable
Splits the input sequence of strings based on a pattern even across subsequent elements if needed.
SpmcLinkedArrayQueue<T> - Class in hu.akarnokd.rxjava3.util
A single-producer multiple-conumer queue implementation with array islands.
SpmcLinkedArrayQueue(int) - Constructor for class hu.akarnokd.rxjava3.util.SpmcLinkedArrayQueue
 
SpscOneQueue<T> - Class in hu.akarnokd.rxjava3.util
A single-producer single-consumer queue with exactly one slot of value.
SpscOneQueue() - Constructor for class hu.akarnokd.rxjava3.util.SpscOneQueue
 
stacktrace() - Method in exception hu.akarnokd.rxjava3.debug.RxJavaAssemblyException
Returns the captured and filtered stacktrace.
start(Supplier<? extends T>) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Invokes the specified function asynchronously and returns an Flowable that emits the result.
start(Supplier<? extends T>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Invokes the specified function asynchronously on the specified Scheduler and returns an Flowable that emits the result.
start(Supplier<? extends T>) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Invokes the specified function asynchronously and returns an Observable that emits the result.
start(Supplier<? extends T>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Invokes the specified function asynchronously on the specified Scheduler and returns an Observable that emits the result.
start() - Method in class hu.akarnokd.rxjava3.schedulers.ParallelScheduler
 
startFuture(Supplier<? extends Future<? extends T>>) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Invokes the asynchronous function immediately, surfacing the result through an Observable.
startFuture(Supplier<? extends Future<? extends T>>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Invokes the asynchronous function immediately, surfacing the result through an Observable and waits on the specified Scheduler.
startFuture(Supplier<? extends Future<? extends T>>) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Invokes the asynchronous function immediately, surfacing the result through an Observable.
startFuture(Supplier<? extends Future<? extends T>>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Invokes the asynchronous function immediately, surfacing the result through an Observable and waits on the specified Scheduler.
StatementCompletable - Class in hu.akarnokd.rxjava3.expr
Imperative statements expressed as Completable operators.
StatementFlowable - Class in hu.akarnokd.rxjava3.expr
Imperative statements expressed as Flowable operators.
StatementMaybe - Class in hu.akarnokd.rxjava3.expr
Imperative statements expressed as Maybe operators.
StatementObservable - Class in hu.akarnokd.rxjava3.expr
Imperative statements expressed as Observable operators.
StatementSingle - Class in hu.akarnokd.rxjava3.expr
Imperative statements expressed as Single operators.
StringFlowable - Class in hu.akarnokd.rxjava3.string
Utility class for String operations with Flowables.
StringObservable - Class in hu.akarnokd.rxjava3.string
Utility class for String operations with Observables.
Subjects - Class in hu.akarnokd.rxjava3.subjects
Utility methods to work with RxJava 2 Subjects.
subscribe(Subscriber<? super Void>) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
 
subscribe() - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Subscribe to this Nono and ignore the events it produces.
subscribe(Action) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Subscribe to this Nono and execute the given action if this Nono completes.
subscribe(Action, Consumer<? super Throwable>) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Subscribe to this Nono and execute the given action if this Nono completes or call the consumer if this Nono terminates with an error.
subscribe(Subscriber<? super T>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
 
subscribe() - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Subscribe to this Perhaps and ignore any signal it produces.
subscribe(Consumer<? super T>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Subscribes to this Perhaps and calls the onNext if this Perhaps succeeds.
subscribe(Consumer<? super T>, Consumer<? super Throwable>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Subscribes to this Perhaps and calls the appropriate callback for the resulting signal.
subscribe(Consumer<? super T>, Consumer<? super Throwable>, Action) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Subscribes to this Perhaps and calls the appropriate callback for the resulting signal.
subscribe(Subscriber<? super T>) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
 
subscribe() - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Subscribe to this Solo and ignore any signal it produces.
subscribe(Consumer<? super T>) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Subscribes to this Solo and calls the onNext if this Solo succeeds.
subscribe(Consumer<? super T>, Consumer<? super Throwable>) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Subscribes to this Solo and calls the appropriate callback for the resulting signal.
subscribe(Consumer<? super T>, Consumer<? super Throwable>, Action) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Subscribes to this Solo and calls the appropriate callback for the resulting signal.
subscribe(Publisher<T>[], int) - Method in class hu.akarnokd.rxjava3.operators.BasicMergeSubscription
 
subscribe(ParallelFlowable<T>) - Method in class hu.akarnokd.rxjava3.operators.BasicMergeSubscription
 
subscribeActual(Subscriber<? super Void>) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Implement this method to signal the terminal events to the given subscriber.
subscribeActual(Subscriber<? super Void>) - Method in class hu.akarnokd.rxjava3.basetypes.NonoProcessor
 
subscribeActual(Subscriber<? super T>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Implement this method to react to a Subscriber subscribing to this Perhaps.
subscribeActual(Subscriber<? super T>) - Method in class hu.akarnokd.rxjava3.basetypes.PerhapsProcessor
 
subscribeActual(Subscriber<? super T>) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Implement this method to react to a Subscriber subscribing to this Solo.
subscribeActual(Subscriber<? super T>) - Method in class hu.akarnokd.rxjava3.basetypes.SoloProcessor
 
subscribeActual(Observer<? super Double>) - Method in class hu.akarnokd.rxjava3.math.ObservableAverageDouble
 
subscribeActual(Observer<? super Float>) - Method in class hu.akarnokd.rxjava3.math.ObservableAverageFloat
 
subscribeActual(Observer<? super Double>) - Method in class hu.akarnokd.rxjava3.math.ObservableSumDouble
 
subscribeActual(Observer<? super Float>) - Method in class hu.akarnokd.rxjava3.math.ObservableSumFloat
 
subscribeActual(Observer<? super Long>) - Method in class hu.akarnokd.rxjava3.math.ObservableSumLong
 
subscribeActual(Subscriber<? super T>) - Method in class hu.akarnokd.rxjava3.processors.DispatchWorkProcessor
 
subscribeActual(Observer<? super T>) - Method in class hu.akarnokd.rxjava3.subjects.DispatchWorkSubject
 
subscribeActual(Observer<? super T>) - Method in class hu.akarnokd.rxjava3.subjects.UnicastWorkSubject
 
subscribeAutoDispose(Completable, CompositeDisposable, Action) - Static method in class hu.akarnokd.rxjava3.consumers.CompletableConsumers
Wraps the given onXXX callbacks into a Disposable CompletableObserver, adds it to the given CompositeDisposable and ensures, that if the upstream completes or this particlular Disposable is disposed, the CompletableObserver is removed from the given composite.
subscribeAutoDispose(Completable, CompositeDisposable, Action, Consumer<? super Throwable>) - Static method in class hu.akarnokd.rxjava3.consumers.CompletableConsumers
Wraps the given onXXX callbacks into a Disposable CompletableObserver, adds it to the given CompositeDisposable and ensures, that if the upstream completes or this particlular Disposable is disposed, the CompletableObserver is removed from the given composite.
subscribeAutoDispose(Flowable<T>, CompositeDisposable, Consumer<? super T>) - Static method in class hu.akarnokd.rxjava3.consumers.FlowableConsumers
Wraps the given onXXX callbacks into a Disposable Subscriber, adds it to the given CompositeDisposable and ensures, that if the upstream completes or this particlular Disposable is disposed, the Subscriber is removed from the given composite.
subscribeAutoDispose(Flowable<T>, CompositeDisposable, Consumer<? super T>, Consumer<? super Throwable>) - Static method in class hu.akarnokd.rxjava3.consumers.FlowableConsumers
Wraps the given onXXX callbacks into a Disposable Subscriber, adds it to the given CompositeDisposable and ensures, that if the upstream completes or this particlular Disposable is disposed, the Subscriber is removed from the given composite.
subscribeAutoDispose(Flowable<T>, CompositeDisposable, Consumer<? super T>, Consumer<? super Throwable>, Action) - Static method in class hu.akarnokd.rxjava3.consumers.FlowableConsumers
Wraps the given onXXX callbacks into a Disposable Subscriber, adds it to the given CompositeDisposable and ensures, that if the upstream completes or this particlular Disposable is disposed, the Subscriber is removed from the given composite.
subscribeAutoDispose(Maybe<T>, CompositeDisposable, Consumer<? super T>) - Static method in class hu.akarnokd.rxjava3.consumers.MaybeConsumers
Wraps the given onXXX callbacks into a Disposable MaybeObserver, adds it to the given CompositeDisposable and ensures, that if the upstream completes or this particlular Disposable is disposed, the MaybeObserver is removed from the given composite.
subscribeAutoDispose(Maybe<T>, CompositeDisposable, Consumer<? super T>, Consumer<? super Throwable>) - Static method in class hu.akarnokd.rxjava3.consumers.MaybeConsumers
Wraps the given onXXX callbacks into a Disposable MaybeObserver, adds it to the given CompositeDisposable and ensures, that if the upstream completes or this particlular Disposable is disposed, the MaybeObserver is removed from the given composite.
subscribeAutoDispose(Maybe<T>, CompositeDisposable, Consumer<? super T>, Consumer<? super Throwable>, Action) - Static method in class hu.akarnokd.rxjava3.consumers.MaybeConsumers
Wraps the given onXXX callbacks into a Disposable MaybeObserver, adds it to the given CompositeDisposable and ensures, that if the upstream completes or this particlular Disposable is disposed, the MaybeObserver is removed from the given composite.
subscribeAutoDispose(Observable<T>, CompositeDisposable, Consumer<? super T>) - Static method in class hu.akarnokd.rxjava3.consumers.ObservableConsumers
Wraps the given onXXX callbacks into a Disposable Observer, adds it to the given CompositeDisposable and ensures, that if the upstream completes or this particlular Disposable is disposed, the Observer is removed from the given composite.
subscribeAutoDispose(Observable<T>, CompositeDisposable, Consumer<? super T>, Consumer<? super Throwable>) - Static method in class hu.akarnokd.rxjava3.consumers.ObservableConsumers
Wraps the given onXXX callbacks into a Disposable Observer, adds it to the given CompositeDisposable and ensures, that if the upstream completes or this particlular Disposable is disposed, the Observer is removed from the given composite.
subscribeAutoDispose(Observable<T>, CompositeDisposable, Consumer<? super T>, Consumer<? super Throwable>, Action) - Static method in class hu.akarnokd.rxjava3.consumers.ObservableConsumers
Wraps the given onXXX callbacks into a Disposable Observer, adds it to the given CompositeDisposable and ensures, that if the upstream completes or this particlular Disposable is disposed, the Observer is removed from the given composite.
subscribeAutoDispose(Single<T>, CompositeDisposable, Consumer<? super T>) - Static method in class hu.akarnokd.rxjava3.consumers.SingleConsumers
Wraps the given onXXX callbacks into a Disposable Observer, adds it to the given CompositeDisposable and ensures, that if the upstream completes or this particlular Disposable is disposed, the Observer is removed from the given composite.
subscribeAutoDispose(Single<T>, CompositeDisposable, Consumer<? super T>, Consumer<? super Throwable>) - Static method in class hu.akarnokd.rxjava3.consumers.SingleConsumers
Wraps the given onXXX callbacks into a Disposable Observer, adds it to the given CompositeDisposable and ensures, that if the upstream completes or this particlular Disposable is disposed, the Observer is removed from the given composite.
subscribeOn(Scheduler) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Subscribes to the upstream on the specified Scheduler.
subscribeOn(Scheduler) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Subscribes to the upstream Perhaps and requests on the specified Scheduler.
subscribeOn(Scheduler) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Returns a Solo that subscribes to this Solo on the specified scheduler and makes sure downstream requests are forwarded there as well.
subscribeWith(E) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Subscribe with the given subscriber and return the same subscriber, allowing chaining methods on it or fluently reusing the instance.
subscribeWith(E) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Subscribe with a Subscriber (subclass) and return it as is.
subscribeWith(E) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Subscribe with a Subscriber (subclass) and return it as is.
sumDouble(Publisher<Double>) - Static method in class hu.akarnokd.rxjava3.math.MathFlowable
 
sumDouble(ObservableSource<Double>) - Static method in class hu.akarnokd.rxjava3.math.MathObservable
 
sumDouble() - Static method in class hu.akarnokd.rxjava3.parallel.ParallelTransformers
Sums the numbers as longs on each rail.
sumFloat(Publisher<Float>) - Static method in class hu.akarnokd.rxjava3.math.MathFlowable
 
sumFloat(ObservableSource<Float>) - Static method in class hu.akarnokd.rxjava3.math.MathObservable
 
sumInt(Publisher<Integer>) - Static method in class hu.akarnokd.rxjava3.math.MathFlowable
 
sumInt(ObservableSource<Integer>) - Static method in class hu.akarnokd.rxjava3.math.MathObservable
 
sumInteger() - Static method in class hu.akarnokd.rxjava3.parallel.ParallelTransformers
Sums the numbers as integers on each rail.
sumLong(Publisher<Long>) - Static method in class hu.akarnokd.rxjava3.math.MathFlowable
 
sumLong(ObservableSource<Long>) - Static method in class hu.akarnokd.rxjava3.math.MathObservable
 
sumLong() - Static method in class hu.akarnokd.rxjava3.parallel.ParallelTransformers
Sums the numbers as longs on each rail.
switchCase(Supplier<? extends K>, Map<? super K, ? extends CompletableSource>, CompletableSource) - Static method in class hu.akarnokd.rxjava3.expr.StatementCompletable
Return a particular one of several possible Completables based on a case selector, or a default Completable if the case selector does not map to a particular one.
switchCase(Supplier<? extends K>, Map<? super K, ? extends Publisher<? extends R>>) - Static method in class hu.akarnokd.rxjava3.expr.StatementFlowable
Return a particular one of several possible Observables based on a case selector.
switchCase(Supplier<? extends K>, Map<? super K, ? extends Publisher<? extends R>>, Scheduler) - Static method in class hu.akarnokd.rxjava3.expr.StatementFlowable
Return a particular one of several possible Observables based on a case selector and run it on the designated scheduler.
switchCase(Supplier<? extends K>, Map<? super K, ? extends Publisher<? extends R>>, Publisher<? extends R>) - Static method in class hu.akarnokd.rxjava3.expr.StatementFlowable
Return a particular one of several possible Observables based on a case selector, or a default Flowable if the case selector does not map to a particular one.
switchCase(Supplier<? extends K>, Map<? super K, ? extends MaybeSource<? extends R>>) - Static method in class hu.akarnokd.rxjava3.expr.StatementMaybe
Return a particular one of several possible Maybes based on a case selector.
switchCase(Supplier<? extends K>, Map<? super K, ? extends MaybeSource<? extends R>>, Scheduler) - Static method in class hu.akarnokd.rxjava3.expr.StatementMaybe
Return a particular one of several possible Maybes based on a case selector and run it on the designated scheduler.
switchCase(Supplier<? extends K>, Map<? super K, ? extends MaybeSource<? extends R>>, MaybeSource<? extends R>) - Static method in class hu.akarnokd.rxjava3.expr.StatementMaybe
Return a particular one of several possible Maybes based on a case selector, or a default Maybe if the case selector does not map to a particular one.
switchCase(Supplier<? extends K>, Map<? super K, ? extends ObservableSource<? extends R>>) - Static method in class hu.akarnokd.rxjava3.expr.StatementObservable
Return a particular one of several possible Observables based on a case selector.
switchCase(Supplier<? extends K>, Map<? super K, ? extends ObservableSource<? extends R>>, Scheduler) - Static method in class hu.akarnokd.rxjava3.expr.StatementObservable
Return a particular one of several possible Observables based on a case selector and run it on the designated scheduler.
switchCase(Supplier<? extends K>, Map<? super K, ? extends ObservableSource<? extends R>>, ObservableSource<? extends R>) - Static method in class hu.akarnokd.rxjava3.expr.StatementObservable
Return a particular one of several possible Observables based on a case selector, or a default Observable if the case selector does not map to a particular one.
switchCase(Supplier<? extends K>, Map<? super K, ? extends SingleSource<? extends R>>, SingleSource<? extends R>) - Static method in class hu.akarnokd.rxjava3.expr.StatementSingle
Return a particular one of several possible Singles based on a case selector, or a default Single if the case selector does not map to a particular one.
switchFlatMap(Function<? super T, ? extends Publisher<? extends R>>, int) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Combination of switchMap and flatMap where there is a limit on the number of concurrent sources to be flattened into a single sequence and if the operator is at the given maximum active count, a newer source Publisher will switch out the oldest active source Publisher being merged.
switchFlatMap(Function<? super T, ? extends Publisher<? extends R>>, int, int) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Combination of switchMap and flatMap where there is a limit on the number of concurrent sources to be flattened into a single sequence and if the operator is at the given maximum active count, a newer source Publisher will switch out the oldest active source Publisher being merged.
switchIfEmpty(Perhaps<? extends T>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Switch to the other Perhaps if this Perhaps is empty.
switchIfEmpty(Iterable<? extends Publisher<? extends T>>) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
If the upstream turns out to be empty, it keeps switching to the alternative sources until one of them is non-empty or there are no more alternatives remaining.
switchIfEmptyArray(Publisher<? extends T>...) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
If the upstream turns out to be empty, it keeps switching to the alternative sources until one of them is non-empty or there are no more alternatives remaining.
switchOnFirst(Predicate<? super T>, Function<? super T, ? extends Publisher<? extends T>>) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Switches to an alternate flow if the very first item of the main flow matches the given predicate.

T

tagBiFunction(BiFunction<T1, T2, R>, String) - Static method in class hu.akarnokd.rxjava3.functions.FunctionTagging
 
tagFunction(Function<T, R>, String) - Static method in class hu.akarnokd.rxjava3.functions.FunctionTagging
 
tagFunction3(Function3<T1, T2, T3, R>, String) - Static method in class hu.akarnokd.rxjava3.functions.FunctionTagging
 
tagFunction4(Function4<T1, T2, T3, T4, R>, String) - Static method in class hu.akarnokd.rxjava3.functions.FunctionTagging
 
tagFunction5(Function5<T1, T2, T3, T4, T5, R>, String) - Static method in class hu.akarnokd.rxjava3.functions.FunctionTagging
 
tagFunction6(Function6<T1, T2, T3, T4, T5, T6, R>, String) - Static method in class hu.akarnokd.rxjava3.functions.FunctionTagging
 
tagFunction7(Function7<T1, T2, T3, T4, T5, T6, T7, R>, String) - Static method in class hu.akarnokd.rxjava3.functions.FunctionTagging
 
tagFunction8(Function8<T1, T2, T3, T4, T5, T6, T7, T8, R>, String) - Static method in class hu.akarnokd.rxjava3.functions.FunctionTagging
 
tagFunction9(Function9<T1, T2, T3, T4, T5, T6, T7, T8, T9, R>, String) - Static method in class hu.akarnokd.rxjava3.functions.FunctionTagging
 
takeUntil(Publisher<?>) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Run this Nono and cancel it when the other Publisher signals an item or completes.
takeUntil(Publisher<?>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Try consuming this Perhaps until the other Publisher signals an item or completes which then completes the Perhaps.
takeUntil(Publisher<?>) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Signal a NoSuchElementException if the other signals before this Solo signals.
test() - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Create a TestSubscriber, subscribe it to this Nono and return the TestSubscriber itself.
test(boolean) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Create a TestSubscriber, optionally cancel it, subscribe it to this Nono and return the TestSubscriber itself.
test() - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Creates a TestSubscriber and subscribes it to this Perhaps.
test(boolean) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Creates a TestSubscriber, optionally cancels it, and subscribes it to this Perhaps.
test(long) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Creates a TestSubscriber with the given initial request and subscribes it to this Perhaps.
test(long, boolean) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Creates a TestSubscriber with the given initial request, optionally cancels it, and subscribes it to this Perhaps.
test() - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Creates a TestSubscriber and subscribes it to this Solo.
test(boolean) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Creates a TestSubscriber, optionally cancels it, and subscribes it to this Solo.
test(long) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Creates a TestSubscriber with the given initial request and subscribes it to this Solo.
test(long, boolean) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Creates a TestSubscriber with the given initial request, optionally cancels it, and subscribes it to this Solo.
then(Function<? super T, ? extends R>) - Method in class hu.akarnokd.rxjava3.joins.JoinObservable
Matches when the Observable has an available item and projects the item by invoking the selector function.
then(Function<? super T1, ? extends R>) - Method in class hu.akarnokd.rxjava3.joins.Pattern1
Matches when all observable sequences have an available element and projects the elements by invoking the selector function.
then(BiFunction<T1, T2, R>) - Method in class hu.akarnokd.rxjava3.joins.Pattern2
Matches when all observable sequences have an available element and projects the elements by invoking the selector function.
then(Function3<T1, T2, T3, R>) - Method in class hu.akarnokd.rxjava3.joins.Pattern3
Matches when all observable sequences have an available element and projects the elements by invoking the selector function.
then(Function4<T1, T2, T3, T4, R>) - Method in class hu.akarnokd.rxjava3.joins.Pattern4
Matches when all observable sequences have an available element and projects the elements by invoking the selector function.
then(Function5<T1, T2, T3, T4, T5, R>) - Method in class hu.akarnokd.rxjava3.joins.Pattern5
Matches when all observable sequences have an available element and projects the elements by invoking the selector function.
then(Function6<T1, T2, T3, T4, T5, T6, R>) - Method in class hu.akarnokd.rxjava3.joins.Pattern6
Matches when all observable sequences have an available element and projects the elements by invoking the selector function.
then(Function7<T1, T2, T3, T4, T5, T6, T7, R>) - Method in class hu.akarnokd.rxjava3.joins.Pattern7
Matches when all observable sequences have an available element and projects the elements by invoking the selector function.
then(Function8<T1, T2, T3, T4, T5, T6, T7, T8, R>) - Method in class hu.akarnokd.rxjava3.joins.Pattern8
Matches when all observable sequences have an available element and projects the elements by invoking the selector function.
then(Function9<T1, T2, T3, T4, T5, T6, T7, T8, T9, R>) - Method in class hu.akarnokd.rxjava3.joins.Pattern9
Matches when all observable sequences have an available element and projects the elements by invoking the selector function.
then(Function<? super Object[], R>) - Method in class hu.akarnokd.rxjava3.joins.PatternN
Matches when all observable sequences have an available element and projects the elements by invoking the selector function.
timeout(long, TimeUnit) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Signals a TimeoutException if this Nono doesn't complete within the specified timeout.
timeout(long, TimeUnit, Nono) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Switches to the fallback Nono if this Nono doesn't complete within the specified timeout.
timeout(long, TimeUnit, Scheduler) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Signals a TimeoutException if this Nono doesn't complete within the specified timeout.
timeout(long, TimeUnit, Scheduler, Nono) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Switches to the fallback Nono if this Nono doesn't complete within the specified timeout.
timeout(Publisher<?>) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Signal a TimeoutException if the other Publisher signals an item or completes before this Nono completes.
timeout(Publisher<?>, Nono) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Switch to the fallback Nono if the other Publisher signals an item or completes before this Nono completes.
timeout(long, TimeUnit) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Signals a TimeoutException if the Perhaps doesn't signal an item within the specified time.
timeout(long, TimeUnit, Scheduler) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Signals a TimeoutException if the Perhaps doesn't signal an item or (terminates) within the specified time.
timeout(long, TimeUnit, Perhaps<? extends T>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Switch to the fallback Perhaps if this Perhaps doesn't signal an item (or terminates) within the specified time.
timeout(long, TimeUnit, Scheduler, Perhaps<? extends T>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Switch to the fallback Perhaps if this Perhaps doesn't signal an item (or terminates) within the specified time.
timeout(Publisher<?>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Signal a TimeoutException if the other Publisher signals an item or completes before this Perhaps does.
timeout(Publisher<?>, Perhaps<? extends T>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Switch to the fallback Perhaps if the other Publisher signals an item or completes before this Perhaps does.
timeout(long, TimeUnit) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Signal a TimeoutException if there is no item from this Solo within the given timeout time.
timeout(long, TimeUnit, Scheduler) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Signal a TimeoutException if there is no item from this Solo within the given timeout time, running on the specified scheduler.
timeout(long, TimeUnit, Solo<T>) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Fall back to another Solo if this Solo doesn't signal within the given time period.
timeout(long, TimeUnit, Scheduler, Solo<T>) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Fall back to another Solo if this Solo doesn't signal within the given time period, waiting on the specified scheduler.
timeout(Publisher<?>) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Signal a TimeoutException if the other Publisher signals or completes before this Solo signals a value.
timeout(Publisher<?>, Solo<T>) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Fall back to another Solo if the other Publisher signals or completes before this Solo signals a value.
timeoutLast(long, TimeUnit) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Emit the last item when the upstream completes or the the latest received if the specified timeout elapses since the last received item.
timeoutLast(long, TimeUnit, Scheduler) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Emit the last item when the upstream completes or the the latest received if the specified timeout elapses since the last received item.
timeoutLastAbsolute(long, TimeUnit) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Emit the last item when the upstream completes or the the latest received if the specified timeout elapses since the start of the sequence.
timeoutLastAbsolute(long, TimeUnit, Scheduler) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Emit the last item when the upstream completes or the the latest received if the specified timeout elapses since the start of the sequence.
timer(long, TimeUnit) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Completes after the specified amount of time on the computation scheduler.
timer(long, TimeUnit, Scheduler) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Completes after the specified amount of time on the specified scheduler.
timer(long, TimeUnit) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Signals a 0L after the specified amount of time has passed since subscription.
timer(long, TimeUnit, Scheduler) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Signals a 0L after the specified amount of time has passed since subscription on the specified scheduler.
timer(long, TimeUnit) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Signals a 0L after the specified amount of time has passed since subscription.
timer(long, TimeUnit, Scheduler) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Signals a 0L after the specified amount of time has passed since subscription on the specified scheduler.
to(Function<? super Nono, R>) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Fluently convert this Nono via a function callback into some type.
to(Function<? super Perhaps<T>, R>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Applies the function, fluently to this Perhaps and returns the value it returns.
to(Function<? super Solo<T>, R>) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Applies the function, fluently to this Solo and returns the value it returns.
toAsync(Action) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous action call into an asynchronous function call through a Flowable.
toAsync(Consumer<? super T1>) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous action call into an asynchronous function call through a Flowable.
toAsync(Function<? super T1, ? extends R>) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous function call into an asynchronous function call through a Flowable.
toAsync(BiConsumer<? super T1, ? super T2>) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous action call into an asynchronous function call through a Flowable.
toAsync(BiFunction<? super T1, ? super T2, ? extends R>) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous function call into an asynchronous function call through a Flowable.
toAsync(Consumer3<? super T1, ? super T2, ? super T3>) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous action call into an asynchronous function call through an Flowable.
toAsync(Function3<? super T1, ? super T2, ? super T3, ? extends R>) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous function call into an asynchronous function call through an Flowable.
toAsync(Consumer4<? super T1, ? super T2, ? super T3, ? super T4>) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous action call into an asynchronous function call through an Flowable.
toAsync(Function4<? super T1, ? super T2, ? super T3, ? super T4, ? extends R>) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous function call into an asynchronous function call through an Flowable.
toAsync(Consumer5<? super T1, ? super T2, ? super T3, ? super T4, ? super T5>) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous action call into an asynchronous function call through an Flowable.
toAsync(Function5<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? extends R>) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous function call into an asynchronous function call through an Flowable.
toAsync(Consumer6<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6>) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous action call into an asynchronous function call through an Flowable.
toAsync(Function6<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? extends R>) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous function call into an asynchronous function call through an Flowable.
toAsync(Consumer7<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7>) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous action call into an asynchronous function call through an Flowable.
toAsync(Function7<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? extends R>) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous function call into an asynchronous function call through an Flowable.
toAsync(Consumer8<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8>) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous action call into an asynchronous function call through an Flowable.
toAsync(Function8<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? extends R>) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous function call into an asynchronous function call through an Flowable.
toAsync(Consumer9<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? super T9>) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous action call into an asynchronous function call through an Flowable.
toAsync(Function9<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? super T9, ? extends R>) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous function call into an asynchronous function call through an Flowable.
toAsync(Action, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous action call into an asynchronous function call through a Flowable.
toAsync(Consumer<? super T1>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous action call into an asynchronous function call through a Flowable.
toAsync(Function<? super T1, ? extends R>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous function call into an asynchronous function call through a Flowable.
toAsync(BiConsumer<? super T1, ? super T2>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous action call into an asynchronous function call through a Flowable.
toAsync(BiFunction<? super T1, ? super T2, ? extends R>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous function call into an asynchronous function call through a Flowable.
toAsync(Consumer3<? super T1, ? super T2, ? super T3>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous action call into an asynchronous function call through an Flowable.
toAsync(Function3<? super T1, ? super T2, ? super T3, ? extends R>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous function call into an asynchronous function call through an Flowable.
toAsync(Consumer4<? super T1, ? super T2, ? super T3, ? super T4>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous action call into an asynchronous function call through an Flowable.
toAsync(Function4<? super T1, ? super T2, ? super T3, ? super T4, ? extends R>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous function call into an asynchronous function call through an Flowable.
toAsync(Consumer5<? super T1, ? super T2, ? super T3, ? super T4, ? super T5>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous action call into an asynchronous function call through an Flowable.
toAsync(Function5<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? extends R>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous function call into an asynchronous function call through an Flowable.
toAsync(Consumer6<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous action call into an asynchronous function call through an Flowable.
toAsync(Function6<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? extends R>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous function call into an asynchronous function call through an Flowable.
toAsync(Consumer7<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous action call into an asynchronous function call through an Flowable.
toAsync(Function7<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? extends R>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous function call into an asynchronous function call through an Flowable.
toAsync(Consumer8<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous action call into an asynchronous function call through an Flowable.
toAsync(Function8<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? extends R>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous function call into an asynchronous function call through an Flowable.
toAsync(Consumer9<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? super T9>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous action call into an asynchronous function call through an Flowable.
toAsync(Function9<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? super T9, ? extends R>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous function call into an asynchronous function call through an Flowable.
toAsync(Action) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous action call into an asynchronous function call through a Observable.
toAsync(Consumer<? super T1>) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous action call into an asynchronous function call through a Observable.
toAsync(Function<? super T1, ? extends R>) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous function call into an asynchronous function call through a Observable.
toAsync(BiConsumer<? super T1, ? super T2>) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous action call into an asynchronous function call through a Observable.
toAsync(BiFunction<? super T1, ? super T2, ? extends R>) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous function call into an asynchronous function call through a Observable.
toAsync(Consumer3<? super T1, ? super T2, ? super T3>) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous action call into an asynchronous function call through an Observable.
toAsync(Function3<? super T1, ? super T2, ? super T3, ? extends R>) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous function call into an asynchronous function call through an Observable.
toAsync(Consumer4<? super T1, ? super T2, ? super T3, ? super T4>) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous action call into an asynchronous function call through an Observable.
toAsync(Function4<? super T1, ? super T2, ? super T3, ? super T4, ? extends R>) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous function call into an asynchronous function call through an Observable.
toAsync(Consumer5<? super T1, ? super T2, ? super T3, ? super T4, ? super T5>) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous action call into an asynchronous function call through an Observable.
toAsync(Function5<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? extends R>) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous function call into an asynchronous function call through an Observable.
toAsync(Consumer6<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6>) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous action call into an asynchronous function call through an Observable.
toAsync(Function6<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? extends R>) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous function call into an asynchronous function call through an Observable.
toAsync(Consumer7<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7>) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous action call into an asynchronous function call through an Observable.
toAsync(Function7<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? extends R>) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous function call into an asynchronous function call through an Observable.
toAsync(Consumer8<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8>) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous action call into an asynchronous function call through an Observable.
toAsync(Function8<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? extends R>) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous function call into an asynchronous function call through an Observable.
toAsync(Consumer9<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? super T9>) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous action call into an asynchronous function call through an Observable.
toAsync(Function9<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? super T9, ? extends R>) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous function call into an asynchronous function call through an Observable.
toAsync(Action, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous action call into an asynchronous function call through a Observable.
toAsync(Consumer<? super T1>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous action call into an asynchronous function call through a Observable.
toAsync(Function<? super T1, ? extends R>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous function call into an asynchronous function call through a Observable.
toAsync(BiConsumer<? super T1, ? super T2>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous action call into an asynchronous function call through a Observable.
toAsync(BiFunction<? super T1, ? super T2, ? extends R>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous function call into an asynchronous function call through a Observable.
toAsync(Consumer3<? super T1, ? super T2, ? super T3>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous action call into an asynchronous function call through an Observable.
toAsync(Function3<? super T1, ? super T2, ? super T3, ? extends R>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous function call into an asynchronous function call through an Observable.
toAsync(Consumer4<? super T1, ? super T2, ? super T3, ? super T4>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous action call into an asynchronous function call through an Observable.
toAsync(Function4<? super T1, ? super T2, ? super T3, ? super T4, ? extends R>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous function call into an asynchronous function call through an Observable.
toAsync(Consumer5<? super T1, ? super T2, ? super T3, ? super T4, ? super T5>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous action call into an asynchronous function call through an Observable.
toAsync(Function5<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? extends R>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous function call into an asynchronous function call through an Observable.
toAsync(Consumer6<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous action call into an asynchronous function call through an Observable.
toAsync(Function6<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? extends R>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous function call into an asynchronous function call through an Observable.
toAsync(Consumer7<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous action call into an asynchronous function call through an Observable.
toAsync(Function7<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? extends R>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous function call into an asynchronous function call through an Observable.
toAsync(Consumer8<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous action call into an asynchronous function call through an Observable.
toAsync(Function8<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? extends R>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous function call into an asynchronous function call through an Observable.
toAsync(Consumer9<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? super T9>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous action call into an asynchronous function call through an Observable.
toAsync(Function9<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? super T9, ? extends R>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous function call into an asynchronous function call through an Observable.
toAsyncArray(Consumer<? super Object[]>) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous action call into an asynchronous function call through an Flowable.
toAsyncArray(Function<? super Object[], ? extends R>) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous function call into an asynchronous function call through an Flowable.
toAsyncArray(Consumer<? super Object[]>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous action call into an asynchronous function call through an Flowable.
toAsyncArray(Function<? super Object[], ? extends R>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous function call into an asynchronous function call through an Flowable.
toAsyncArray(Consumer<? super Object[]>) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous action call into an asynchronous function call through an Observable.
toAsyncArray(Function<? super Object[], ? extends R>) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous function call into an asynchronous function call through an Observable.
toAsyncArray(Consumer<? super Object[]>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous action call into an asynchronous function call through an Observable.
toAsyncArray(Function<? super Object[], ? extends R>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous function call into an asynchronous function call through an Observable.
toAsyncCallable(Callable<? extends R>) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous function call into an asynchronous function call through a Flowable.
toAsyncCallable(Callable<? extends R>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous function call into an asynchronous function call through a Flowable.
toAsyncCallable(Callable<? extends R>) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous function call into an asynchronous function call through a Observable.
toAsyncCallable(Callable<? extends R>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous function call into an asynchronous function call through a Observable.
toAsyncSupplier(Supplier<? extends R>) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous function call into an asynchronous function call through a Flowable.
toAsyncSupplier(Supplier<? extends R>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncFlowable
Convert a synchronous function call into an asynchronous function call through a Flowable.
toAsyncSupplier(Supplier<? extends R>) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous function call into an asynchronous function call through a Observable.
toAsyncSupplier(Supplier<? extends R>, Scheduler) - Static method in class hu.akarnokd.rxjava3.async.AsyncObservable
Convert a synchronous function call into an asynchronous function call through a Observable.
toCompletable() - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Convert this Nono instance into a Completable.
toFlowable() - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Convert this Nono instance into a Flowable that only terminates.
toFlowable() - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Convert this Perhaps into a Flowable.
toFlowable() - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Converts this Solo into a Flowable.
toFuture() - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Converts this Nono into a Future and signals its single value.
toFuture() - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Converts this Perhaps into a Future and signals its single value or null if this Perhaps is empty.
toFuture() - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Converts this Solo into a Future and signals its single value.
toMaybe() - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Convert this Nono instance into a Maybe that only terminates.
toMaybe() - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Convert this Perhaps into a Maybe.
toObservable() - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Convert this Nono instance into an Observable that only terminates.
toObservable() - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Convert this Perhaps into an Observable.
toObservable() - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Converts this Solo into an Observable.
toObservable() - Method in class hu.akarnokd.rxjava3.joins.JoinObservable
 
toPerhaps() - Method in class hu.akarnokd.rxjava3.basetypes.Nono
Convert this Nono instance into a Perhaps that only terminates.
toSingle() - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Converts this Soli into a Single.

U

UnicastWorkSubject<T> - Class in hu.akarnokd.rxjava3.subjects
A Subject that holds an unbounded queue of items and relays/replays it to a single Observer at a time, making sure that when the Observer disposes, any unconsumed items are available for the next Observer.
unsubscribeOn(Scheduler) - Method in class hu.akarnokd.rxjava3.basetypes.Nono
If the downstream cancels the sequence, the cancellation towards the upstream will happen on the specified Scheduler.
unsubscribeOn(Scheduler) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
If the downstream cancels, the upstream is cancelled on the specified scheduler.
unsubscribeOn(Scheduler) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Returns a Solo which when cancelled, cancels this Solo on the specified scheduler.
using(Supplier<R>, Function<? super R, ? extends Nono>, Consumer<? super R>) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Generate a resource and a Nono based on that resource and then dispose that resource eagerly when the Nono terminates or the downstream cancels the sequence.
using(Supplier<R>, Function<? super R, ? extends Nono>, Consumer<? super R>, boolean) - Static method in class hu.akarnokd.rxjava3.basetypes.Nono
Generate a resource and a Nono based on that resource and then dispose that resource optionally eagerly when the Nono terminates or the downstream cancels the sequence.
using(Supplier<R>, Function<? super R, ? extends Perhaps<? extends T>>, Consumer<? super R>) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Generate a resource and a Perhaps based on that resource and then dispose that resource eagerly when the Perhaps terminates or the downstream cancels the sequence.
using(Supplier<R>, Function<? super R, ? extends Perhaps<? extends T>>, Consumer<? super R>, boolean) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Generate a resource and a Perhaps based on that resource and then dispose that resource eagerly when the Perhaps terminates or the downstream cancels the sequence.
using(Supplier<R>, Function<? super R, ? extends Solo<T>>, Consumer<? super R>) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Generate a resource and a Solo based on that resource and then dispose that resource eagerly when the Solo terminates or the downstream cancels the sequence.
using(Supplier<R>, Function<? super R, ? extends Solo<T>>, Consumer<? super R>, boolean) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Generate a resource and a Solo based on that resource and then dispose that resource eagerly when the Solo terminates or the downstream cancels the sequence.

V

valueOf(String) - Static method in enum hu.akarnokd.rxjava3.async.AnyValue
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum hu.akarnokd.rxjava3.operators.ExpandStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum hu.akarnokd.rxjava3.util.AlwaysFalseBooleanSupplier
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum hu.akarnokd.rxjava3.util.AlwaysTrueBooleanSupplier
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum hu.akarnokd.rxjava3.util.BiFunctionSecondIdentity
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum hu.akarnokd.rxjava3.util.SelfComparator
Returns the enum constant of this type with the specified name.
values() - Static method in enum hu.akarnokd.rxjava3.async.AnyValue
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum hu.akarnokd.rxjava3.operators.ExpandStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum hu.akarnokd.rxjava3.util.AlwaysFalseBooleanSupplier
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum hu.akarnokd.rxjava3.util.AlwaysTrueBooleanSupplier
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum hu.akarnokd.rxjava3.util.BiFunctionSecondIdentity
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum hu.akarnokd.rxjava3.util.SelfComparator
Returns an array containing the constants of this enum type, in the order they are declared.
valve(Publisher<Boolean>) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Relays values until the other Publisher signals false and resumes if the other Publisher signals true again, like closing and opening a valve and not losing any items from the main source.
valve(Publisher<Boolean>, boolean) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Relays values until the other Publisher signals false and resumes if the other Publisher signals true again, like closing and opening a valve and not losing any items from the main source and starts with the specified valve state.
valve(Publisher<Boolean>, boolean, int) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Relays values until the other Publisher signals false and resumes if the other Publisher signals true again, like closing and opening a valve and not losing any items from the main source and starts with the specified valve state and the specified buffer size hint.
valve(ObservableSource<Boolean>) - Static method in class hu.akarnokd.rxjava3.operators.ObservableTransformers
Relays values until the other ObservableSource signals false and resumes if the other ObservableSource signals true again, like closing and opening a valve and not losing any items from the main source.
valve(ObservableSource<Boolean>, boolean) - Static method in class hu.akarnokd.rxjava3.operators.ObservableTransformers
Relays values until the other ObservableSource signals false and resumes if the other ObservableSource signals true again, like closing and opening a valve and not losing any items from the main source and starts with the specified valve state.
valve(ObservableSource<Boolean>, boolean, int) - Static method in class hu.akarnokd.rxjava3.operators.ObservableTransformers
Relays values until the other ObservableSource signals false and resumes if the other ObservableSource signals true again, like closing and opening a valve and not losing any items from the main source and starts with the specified valve state and the specified buffer size hint.

W

when(Iterable<? extends Plan<R>>) - Static method in class hu.akarnokd.rxjava3.joins.JoinObservable
Joins together the results from several patterns via their plans.
when(Plan<R>...) - Static method in class hu.akarnokd.rxjava3.joins.JoinObservable
Joins together the results from several patterns via their plans.
when(Plan<R>) - Static method in class hu.akarnokd.rxjava3.joins.JoinObservable
Joins the results from a pattern via its plan.
when(Plan<R>, Plan<R>) - Static method in class hu.akarnokd.rxjava3.joins.JoinObservable
Joins together the results from two patterns via their plans.
when(Plan<R>, Plan<R>, Plan<R>) - Static method in class hu.akarnokd.rxjava3.joins.JoinObservable
Joins together the results from three patterns via their plans.
when(Plan<R>, Plan<R>, Plan<R>, Plan<R>) - Static method in class hu.akarnokd.rxjava3.joins.JoinObservable
Joins together the results from four patterns via their plans.
when(Plan<R>, Plan<R>, Plan<R>, Plan<R>, Plan<R>) - Static method in class hu.akarnokd.rxjava3.joins.JoinObservable
Joins together the results from five patterns via their plans.
when(Plan<R>, Plan<R>, Plan<R>, Plan<R>, Plan<R>, Plan<R>) - Static method in class hu.akarnokd.rxjava3.joins.JoinObservable
Joins together the results from six patterns via their plans.
when(Plan<R>, Plan<R>, Plan<R>, Plan<R>, Plan<R>, Plan<R>, Plan<R>) - Static method in class hu.akarnokd.rxjava3.joins.JoinObservable
Joins together the results from seven patterns via their plans.
when(Plan<R>, Plan<R>, Plan<R>, Plan<R>, Plan<R>, Plan<R>, Plan<R>, Plan<R>) - Static method in class hu.akarnokd.rxjava3.joins.JoinObservable
Joins together the results from eight patterns via their plans.
when(Plan<R>, Plan<R>, Plan<R>, Plan<R>, Plan<R>, Plan<R>, Plan<R>, Plan<R>, Plan<R>) - Static method in class hu.akarnokd.rxjava3.joins.JoinObservable
Joins together the results from nine patterns via their plans.
whileDo(Publisher<? extends T>, BooleanSupplier) - Static method in class hu.akarnokd.rxjava3.expr.StatementFlowable
Return an Flowable that re-emits the emissions from the source Flowable as long as the condition is true before the first or subsequent subscribe() calls.
whileDo(ObservableSource<? extends T>, BooleanSupplier) - Static method in class hu.akarnokd.rxjava3.expr.StatementObservable
Return an Observable that re-emits the emissions from the source Observable as long as the condition is true before the first or subsequent subscribe() calls.
windowSplit(Predicate<? super T>) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Emits elements into a Flowable window until the given predicate returns true at which point a new Flowable window is emitted; the particular item will be dropped.
windowSplit(Predicate<? super T>, int) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Emits elements into a Flowable window until the given predicate returns true at which point a new Flowable window is emitted; the particular item will be dropped.
windowUntil(Predicate<? super T>) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Emits elements into a Flowable window until the given predicate returns true at which point a new Flowable window is emitted.
windowUntil(Predicate<? super T>, int) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Emits elements into a Flowable window until the given predicate returns true at which point a new Flowable window is emitted.
windowWhile(Predicate<? super T>) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Emits elements into a Flowable window while the given predicate returns true.
windowWhile(Predicate<? super T>, int) - Static method in class hu.akarnokd.rxjava3.operators.FlowableTransformers
Emits elements into a Flowable window while the given predicate returns true.
wrap(Processor<T, T>) - Static method in class hu.akarnokd.rxjava3.processors.FlowableProcessors
Wraps an arbitrary Reactive-Streams Processor into a FlowableProcessor, relaying the onXXX and subscribe() calls to it and providing a rich fluent API on top.

Z

zip(Iterable<? extends Perhaps<? extends T>>, Function<? super Object[], ? extends R>) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Combines the Perhaps values of all the sources via a zipper function into a single resulting value.
zip(Iterable<? extends Solo<? extends T>>, Function<? super Object[], ? extends R>) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Combines the solo values of all the sources via a zipper function into a single resulting value.
zipArray(Function<? super Object[], ? extends R>, Perhaps<? extends T>...) - Static method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Combines the Perhaps values of all the sources via a zipper function into a single resulting value.
zipArray(Function<? super Object[], ? extends R>, Solo<? extends T>...) - Static method in class hu.akarnokd.rxjava3.basetypes.Solo
Combines the solo values of all the sources via a zipper function into a single resulting value.
zipLatest(Function<? super Object[], ? extends R>, Publisher<? extends T>...) - Static method in class hu.akarnokd.rxjava3.operators.Flowables
Zips the latest available values of the source Publishers via a combiner function where the emission rate is determined by the slowest Publisher and the downstream consumption rate.
zipLatest(Function<? super Object[], ? extends R>, Scheduler, Publisher<? extends T>...) - Static method in class hu.akarnokd.rxjava3.operators.Flowables
Zips the latest available values of the source Publishers via a combiner function where the emission rate is determined by the slowest Publisher and the downstream consumption rate.
zipLatest(Iterable<? extends Publisher<? extends T>>, Function<? super Object[], ? extends R>) - Static method in class hu.akarnokd.rxjava3.operators.Flowables
Zips the latest available values of the source Publishers via a combiner function where the emission rate is determined by the slowest Publisher and the downstream consumption rate.
zipLatest(Iterable<? extends Publisher<? extends T>>, Function<? super Object[], ? extends R>, Scheduler) - Static method in class hu.akarnokd.rxjava3.operators.Flowables
Zips the latest available values of the source Publishers via a combiner function where the emission rate is determined by the slowest Publisher and the downstream consumption rate.
zipLatest(Publisher<T1>, Publisher<T2>, BiFunction<? super T1, ? super T2, ? extends R>) - Static method in class hu.akarnokd.rxjava3.operators.Flowables
Zips the latest available values of the source Publishers via a combiner function where the emission rate is determined by the slowest Publisher and the downstream consumption rate.
zipLatest(Publisher<T1>, Publisher<T2>, BiFunction<? super T1, ? super T2, ? extends R>, Scheduler) - Static method in class hu.akarnokd.rxjava3.operators.Flowables
Zips the latest available values of the source Publishers via a combiner function where the emission rate is determined by the slowest Publisher and the downstream consumption rate.
zipLatest(Publisher<T1>, Publisher<T2>, Publisher<T3>, Function3<? super T1, ? super T2, ? super T3, ? extends R>) - Static method in class hu.akarnokd.rxjava3.operators.Flowables
Zips the latest available values of the source Publishers via a combiner function where the emission rate is determined by the slowest Publisher and the downstream consumption rate.
zipLatest(Publisher<T1>, Publisher<T2>, Publisher<T3>, Function3<? super T1, ? super T2, ? super T3, ? extends R>, Scheduler) - Static method in class hu.akarnokd.rxjava3.operators.Flowables
Zips the latest available values of the source Publishers via a combiner function where the emission rate is determined by the slowest Publisher and the downstream consumption rate.
zipLatest(Publisher<T1>, Publisher<T2>, Publisher<T3>, Publisher<T4>, Function4<? super T1, ? super T2, ? super T3, ? super T4, ? extends R>) - Static method in class hu.akarnokd.rxjava3.operators.Flowables
Zips the latest available values of the source Publishers via a combiner function where the emission rate is determined by the slowest Publisher and the downstream consumption rate.
zipLatest(Publisher<T1>, Publisher<T2>, Publisher<T3>, Publisher<T4>, Function4<? super T1, ? super T2, ? super T3, ? super T4, ? extends R>, Scheduler) - Static method in class hu.akarnokd.rxjava3.operators.Flowables
Zips the latest available values of the source Publishers via a combiner function where the emission rate is determined by the slowest Publisher and the downstream consumption rate.
zipWith(Perhaps<? extends U>, BiFunction<? super T, ? super U, ? extends R>) - Method in class hu.akarnokd.rxjava3.basetypes.Perhaps
Zips the value of this Perhaps with the other Perhaps through a BiFunction.
zipWith(Solo<U>, BiFunction<? super T, ? super U, ? extends R>) - Method in class hu.akarnokd.rxjava3.basetypes.Solo
Combines the values of this and the other Solo via a BiFunction.
A B C D E F G H I J L M N O P R S T U V W Z 
Skip navigation links