Package | Description |
---|---|
io.vertx.reactivex.rabbitmq |
Modifier and Type | Field and Description |
---|---|
static io.vertx.lang.rx.TypeArg<RabbitMQConsumer> |
RabbitMQConsumer.__TYPE_ARG |
Modifier and Type | Method and Description |
---|---|
RabbitMQConsumer |
RabbitMQConsumer.endHandler(Handler<Void> endHandler)
Set an end handler.
|
RabbitMQConsumer |
RabbitMQConsumer.exceptionHandler(Handler<Throwable> exceptionHandler)
Set an exception handler on the read stream.
|
RabbitMQConsumer |
RabbitMQConsumer.fetch(long amount)
Fetch the specified
amount of elements. |
RabbitMQConsumer |
RabbitMQConsumer.handler(Handler<RabbitMQMessage> messageArrived)
Set a message handler.
|
static RabbitMQConsumer |
RabbitMQConsumer.newInstance(RabbitMQConsumer arg) |
RabbitMQConsumer |
RabbitMQConsumer.pause()
Pause the stream of incoming messages from queue.
|
RabbitMQConsumer |
RabbitMQConsumer.resume()
Resume reading from a queue.
|
RabbitMQConsumer |
RabbitMQConsumer.setQueueName(String name)
Set the name of the queue.
|
Modifier and Type | Method and Description |
---|---|
Single<RabbitMQConsumer> |
RabbitMQClient.rxBasicConsumer(String queue) |
Single<RabbitMQConsumer> |
RabbitMQClient.rxBasicConsumer(String queue,
QueueOptions options)
Create a consumer with the given
options . |
Modifier and Type | Method and Description |
---|---|
void |
RabbitMQClient.basicConsumer(String queue,
Handler<AsyncResult<RabbitMQConsumer>> resultHandler) |
void |
RabbitMQClient.basicConsumer(String queue,
QueueOptions options,
Handler<AsyncResult<RabbitMQConsumer>> resultHandler)
Create a consumer with the given
options . |
Copyright © 2021 Eclipse. All rights reserved.