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

A

asReadStream(Observable<R>, Function<R, J>) - Static method in class io.vertx.rx.java.ReadStreamSubscriber
 

B

blockingScheduler(Vertx) - Static method in class io.vertx.rx.java.RxHelper
Create a scheduler for a Vertx object, actions can be blocking, they are not executed on Vertx event loop.
blockingScheduler(Vertx, boolean) - Static method in class io.vertx.rx.java.RxHelper
Create a scheduler for a Vertx object, actions can be blocking, they are not executed on Vertx event loop.
BUFFER_SIZE - Static variable in class io.vertx.rx.java.ReadStreamSubscriber
 

C

call(Subscriber<? super T>) - Method in class io.vertx.rx.java.ObservableOnSubscribeAdapter
Subscription
call(Subscriber<? super R>) - Method in class io.vertx.rx.java.ObservableReadStream
 
call(SingleSubscriber<? super T>) - Method in class io.vertx.rx.java.SingleOnSubscribeAdapter
Subscription
call(Subscriber<? super T>) - Method in class io.vertx.rx.java.UnmarshallerOperator
 
consumer - Variable in class io.vertx.rx.java.SingleOnSubscribeAdapter
 
ContextScheduler - Class in io.vertx.rx.java
 
ContextScheduler(Context, boolean) - Constructor for class io.vertx.rx.java.ContextScheduler
 
ContextScheduler(Context, boolean, boolean) - Constructor for class io.vertx.rx.java.ContextScheduler
 
ContextScheduler(Vertx, boolean) - Constructor for class io.vertx.rx.java.ContextScheduler
 
ContextScheduler(Vertx, boolean, boolean) - Constructor for class io.vertx.rx.java.ContextScheduler
 
ContextScheduler(WorkerExecutor) - Constructor for class io.vertx.rx.java.ContextScheduler
 
ContextScheduler(WorkerExecutor, boolean) - Constructor for class io.vertx.rx.java.ContextScheduler
 
ContextScheduler.ContextWorker - Class in io.vertx.rx.java
 
ContextWorker() - Constructor for class io.vertx.rx.java.ContextScheduler.ContextWorker
 
countActions() - Method in class io.vertx.rx.java.ContextScheduler.ContextWorker
 
createWorker() - Method in class io.vertx.rx.java.ContextScheduler
 

D

DEFAULT_MAX_BUFFER_SIZE - Static variable in class io.vertx.rx.java.ObservableReadStream
 
dispatch(AsyncResult<T>) - Method in class io.vertx.rx.java.HandlerAdapter
 

E

endHandler(Handler<Void>) - Method in class io.vertx.rx.java.ReadStreamSubscriber
 
exceptionHandler(Handler<Throwable>) - Method in class io.vertx.rx.java.ReadStreamSubscriber
 

F

fetch(long) - Method in class io.vertx.rx.java.ReadStreamSubscriber
 
fireComplete() - Method in class io.vertx.rx.java.ObservableOnSubscribeAdapter
Fire completed to active observer
fireError(Throwable) - Method in class io.vertx.rx.java.ObservableOnSubscribeAdapter
Fire error to active observer
fireNext(T) - Method in class io.vertx.rx.java.ObservableOnSubscribeAdapter
Fire next to active observer
fireResult(T) - Method in class io.vertx.rx.java.ObservableOnSubscribeAdapter
Fire result to active observer

G

getRequested() - Method in class io.vertx.rx.java.ObservableReadStream
 
getSubscriber() - Method in class io.vertx.rx.java.ObservableOnSubscribeAdapter
Get subscriber

H

handle(AsyncResult<T>) - Method in class io.vertx.rx.java.HandlerAdapter
 
handler(Handler<J>) - Method in class io.vertx.rx.java.ReadStreamSubscriber
 
HandlerAdapter<T> - Class in io.vertx.rx.java
 
HandlerAdapter() - Constructor for class io.vertx.rx.java.HandlerAdapter
 
Helper - Class in io.vertx.lang.rxjava
 
Helper() - Constructor for class io.vertx.lang.rxjava.Helper
 

I

io.vertx.lang.rxjava - package io.vertx.lang.rxjava
 
io.vertx.rx.java - package io.vertx.rx.java
 
isUnsubscribed() - Method in class io.vertx.rx.java.ContextScheduler.ContextWorker
 

L

loadGenerators(ProcessingEnvironment) - Method in class io.vertx.lang.rxjava.RxJavaGeneratorLoader
 

O

ObservableFuture<T> - Class in io.vertx.rx.java
 
ObservableFuture() - Constructor for class io.vertx.rx.java.ObservableFuture
 
observableFuture() - Static method in class io.vertx.rx.java.RxHelper
Create a new ObservableFuture<T> object: an Observable implementation implementing Handler<AsyncResult<T>>.
ObservableHandler<T> - Class in io.vertx.rx.java
 
ObservableHandler() - Constructor for class io.vertx.rx.java.ObservableHandler
 
ObservableHandler(boolean) - Constructor for class io.vertx.rx.java.ObservableHandler
 
observableHandler() - Static method in class io.vertx.rx.java.RxHelper
Create a new ObservableHandler<T> object: an Observable implementation implementing Handler<T>.
observableHandler(boolean) - Static method in class io.vertx.rx.java.RxHelper
Create a new ObservableHandler<T> object: an Observable implementation implementing Handler<T>.

When parameter is false and the event handler completes, the observable will produce the event and complete immediatly after, as a single event is expected.

ObservableOnSubscribeAdapter<T> - Class in io.vertx.rx.java
 
ObservableOnSubscribeAdapter() - Constructor for class io.vertx.rx.java.ObservableOnSubscribeAdapter
 
ObservableReadStream<T,R> - Class in io.vertx.rx.java
Adapt a ReadStream to be an Observable.OnSubscribe that can be used to build Observable.
ObservableReadStream(ReadStream<T>, Function<T, R>) - Constructor for class io.vertx.rx.java.ObservableReadStream
 
ObservableReadStream(ReadStream<T>, Function<T, R>, long) - Constructor for class io.vertx.rx.java.ObservableReadStream
 
onCompleted() - Method in class io.vertx.rx.java.ReadStreamSubscriber
 
onError(Throwable) - Method in class io.vertx.rx.java.ReadStreamSubscriber
 
onError(Action1<Throwable>) - Method in class io.vertx.rx.java.WriteStreamSubscriber
Sets the handler to invoke if the Observable that was subscribed to terminates with an error.
onNext(R) - Method in class io.vertx.rx.java.ReadStreamSubscriber
 
onSubscribed() - Method in class io.vertx.rx.java.HandlerAdapter
 
onSubscribed() - Method in class io.vertx.rx.java.ObservableOnSubscribeAdapter
 
onUnsubscribed() - Method in class io.vertx.rx.java.HandlerAdapter
 
onUnsubscribed() - Method in class io.vertx.rx.java.ObservableOnSubscribeAdapter
 
onWriteStreamEnd(Action0) - Method in class io.vertx.rx.java.WriteStreamSubscriber
Sets the handler to invoke when the adapted WriteStream ends successfully.
onWriteStreamEndError(Action1<Throwable>) - Method in class io.vertx.rx.java.WriteStreamSubscriber
Sets the handler to invoke when the adapted WriteStream ends with an error.
onWriteStreamError(Action1<Throwable>) - Method in class io.vertx.rx.java.WriteStreamSubscriber
Sets the handler to invoke if the adapted WriteStream fails.

P

pause() - Method in class io.vertx.rx.java.ReadStreamSubscriber
 

R

ReadStreamSubscriber<R,J> - Class in io.vertx.rx.java
An RxJava Subscriber that turns an Observable into a ReadStream.
ReadStreamSubscriber(Function<R, J>) - Constructor for class io.vertx.rx.java.ReadStreamSubscriber
 
ReadStreamSubscriber(Function<R, J>, Consumer<Subscriber<R>>) - Constructor for class io.vertx.rx.java.ReadStreamSubscriber
 
resume() - Method in class io.vertx.rx.java.ReadStreamSubscriber
 
RxHelper - Class in io.vertx.rx.java
A set of helpers for RxJava and Vert.x.
RxHelper() - Constructor for class io.vertx.rx.java.RxHelper
 
RxJavaGeneratorLoader - Class in io.vertx.lang.rxjava
 
RxJavaGeneratorLoader() - Constructor for class io.vertx.lang.rxjava.RxJavaGeneratorLoader
 

S

schedule(Action0) - Method in class io.vertx.rx.java.ContextScheduler.ContextWorker
 
schedule(Action0, long, TimeUnit) - Method in class io.vertx.rx.java.ContextScheduler.ContextWorker
 
schedulePeriodically(Action0, long, long, TimeUnit) - Method in class io.vertx.rx.java.ContextScheduler.ContextWorker
 
scheduler(Vertx) - Static method in class io.vertx.rx.java.RxHelper
Create a scheduler for a Vertx object, actions are executed on the event loop.
scheduler(Context) - Static method in class io.vertx.rx.java.RxHelper
Create a scheduler for a Context, actions are executed on the event loop of this context.
schedulerHook(Context) - Static method in class io.vertx.rx.java.RxHelper
Create a scheduler hook for a Context object, the RxJavaSchedulersHook.getIOScheduler() uses a blocking scheduler.
schedulerHook(Vertx) - Static method in class io.vertx.rx.java.RxHelper
Create a scheduler hook for a Vertx object, the RxJavaSchedulersHook.getIOScheduler() uses a blocking scheduler.
SingleOnSubscribeAdapter<T> - Class in io.vertx.rx.java
 
SingleOnSubscribeAdapter(Consumer<Handler<AsyncResult<T>>>) - Constructor for class io.vertx.rx.java.SingleOnSubscribeAdapter
 
subRef - Variable in class io.vertx.rx.java.ObservableOnSubscribeAdapter
 

T

toFuture(Observer<T>) - Static method in class io.vertx.rx.java.RxHelper
Adapt a Subscriber as a Handler<AsyncResult<T>>;.
toFuture(Action1<T>) - Static method in class io.vertx.rx.java.RxHelper
Adapt an item callback as a Handler<AsyncResult<T>>.
toFuture(Action1<T>, Action1<Throwable>) - Static method in class io.vertx.rx.java.RxHelper
Adapt an item callback and an error callback as a Handler<AsyncResult<T>>.
toFuture(Action1<T>, Action1<Throwable>, Action0) - Static method in class io.vertx.rx.java.RxHelper
Adapt an item callback and an error callback as a Handler<AsyncResult<T>>.
toHandler() - Method in class io.vertx.rx.java.ObservableFuture
 
toHandler() - Method in class io.vertx.rx.java.ObservableHandler
 
toHandler(Observer<T>) - Static method in class io.vertx.rx.java.RxHelper
Adapt a Subscriber as a Handler<T>;.

When the event handler completes, the observer will complete immediatly after the event is received, as a single event is expected.

toHandler(Observer<T>, boolean) - Static method in class io.vertx.rx.java.RxHelper
Adapt a Subscriber as a Handler<T>;.

When parameter is false and the event handler completes, the observer will complete immediatly after the event is received, as a single event is expected.

toHandler(Action1<T>) - Static method in class io.vertx.rx.java.RxHelper
Adapt an item callback as a Handler<T>.
toObservable(ReadStream<T>) - Static method in class io.vertx.rx.java.RxHelper
Adapts a Vert.x io.vertx.core.streams.ReadStream to an RxJava Observable.
toObservable(ReadStream<T>, int) - Static method in class io.vertx.rx.java.RxHelper
Adapts a Vert.x io.vertx.core.streams.ReadStream to an RxJava Observable.
toObservable(ReadStream<T>, Function<T, R>) - Static method in class io.vertx.rx.java.RxHelper
Like RxHelper.toObservable(ReadStream) but with a function that adapts the items.
toObservable(ReadStream<T>, Function<T, R>, int) - Static method in class io.vertx.rx.java.RxHelper
Like RxHelper.toObservable(ReadStream, int) but with a function that adapts the items.
toReadStream(Observable<T>) - Static method in class io.vertx.rx.java.RxHelper
Adapts an RxJava Observable to a Vert.x io.vertx.core.streams.ReadStream.
toSubscriber(Handler<AsyncResult<T>>) - Static method in class io.vertx.rx.java.RxHelper
Adapts a Vert.x Handler<AsyncResult<T>> to an RxJava Subscriber.
toSubscriber(WriteStream<T>) - Static method in class io.vertx.rx.java.RxHelper
Adapts a Vert.x WriteStream to an RxJava Subscriber.
toSubscriber(WriteStream<T>, Function<R, T>) - Static method in class io.vertx.rx.java.RxHelper
Like RxHelper.toSubscriber(WriteStream), except the provided mapping function is applied to each Observable item.

U

unmarshaller(Class<T>, ObjectCodec) - Static method in class io.vertx.rx.java.RxHelper
Returns a unmarshaller for the specified java type as a Observable.Operator instance given the the provided com.fasterxml.jackson.databind.ObjectMapper

The marshaller can be used with the Observable.lift(rx.Observable.Operator) method to transform a Observable<Buffer> into a Observable<T>.

The unmarshaller buffers the content until onComplete is called, then unmarshalling happens.

Note that the returned observable will emit at most a single object.

unmarshaller(Class<T>) - Static method in class io.vertx.rx.java.RxHelper
Returns a json unmarshaller for the specified java type as a Observable.Operator instance.

The marshaller can be used with the Observable.lift(rx.Observable.Operator) method to transform a Observable<Buffer> into a Observable<T>.

The unmarshaller buffers the content until onComplete is called, then unmarshalling happens.

Note that the returned observable will emit at most a single object.

unmarshaller(TypeReference<T>) - Static method in class io.vertx.rx.java.RxHelper
Returns a json unmarshaller for the specified java type as a Observable.Operator instance.

The marshaller can be used with the Observable.lift(rx.Observable.Operator) method to transform a Observable<Buffer> into a Observable<T>.

The unmarshaller buffers the content until onComplete is called, then unmarshalling happens.

Note that the returned observable will emit at most a single object.

unmarshaller(TypeReference<T>, ObjectCodec) - Static method in class io.vertx.rx.java.RxHelper
Returns a unmarshaller for the specified java type as a Observable.Operator instance given the the provided com.fasterxml.jackson.databind.ObjectMapper

The marshaller can be used with the Observable.lift(rx.Observable.Operator) method to transform a Observable<Buffer> into a Observable<T>.

The unmarshaller buffers the content until onComplete is called, then unmarshalling happens.

Note that the returned observable will emit at most a single object.

UnmarshallerOperator<T,B> - Class in io.vertx.rx.java
An operator
UnmarshallerOperator(Class<T>) - Constructor for class io.vertx.rx.java.UnmarshallerOperator
 
UnmarshallerOperator(Class<T>, ObjectCodec) - Constructor for class io.vertx.rx.java.UnmarshallerOperator
 
UnmarshallerOperator(TypeReference<T>) - Constructor for class io.vertx.rx.java.UnmarshallerOperator
 
UnmarshallerOperator(TypeReference<T>, ObjectCodec) - Constructor for class io.vertx.rx.java.UnmarshallerOperator
 
unsubscribe() - Method in class io.vertx.rx.java.ContextScheduler.ContextWorker
 
unwrap(Class<?>) - Static method in class io.vertx.lang.rxjava.Helper
Unwrap the type used in RxJava.
unwrap(B) - Method in class io.vertx.rx.java.UnmarshallerOperator
 

W

WriteStreamSubscriber<R> - Class in io.vertx.rx.java
A WriteStream to Subscriber adapter.
WriteStreamSubscriber() - Constructor for class io.vertx.rx.java.WriteStreamSubscriber
 
A B C D E F G H I L O P R S T U W 
Skip navigation links

Copyright © 2022 Eclipse. All rights reserved.