Modifier and Type | Field and Description |
---|---|
static io.vertx.lang.rx.TypeArg<RabbitMQClient> |
__TYPE_ARG |
Constructor and Description |
---|
RabbitMQClient(Object delegate) |
RabbitMQClient(RabbitMQClient delegate) |
Modifier and Type | Method and Description |
---|---|
void |
basicAck(long deliveryTag,
boolean multiple,
Handler<AsyncResult<JsonObject>> resultHandler)
Acknowledge one or several received messages.
|
void |
basicCancel(String consumerTag)
Deprecated.
|
void |
basicCancel(String consumerTag,
Handler<AsyncResult<Void>> resultHandler)
Deprecated.
|
void |
basicConsume(String queue,
String address,
boolean autoAck,
Handler<AsyncResult<String>> resultHandler)
Deprecated.
|
void |
basicConsume(String queue,
String address,
boolean autoAck,
Handler<AsyncResult<String>> resultHandler,
Handler<Throwable> errorHandler)
Deprecated.
|
void |
basicConsume(String queue,
String address,
Handler<AsyncResult<String>> resultHandler)
Deprecated.
|
void |
basicConsumer(String queue,
Handler<AsyncResult<RabbitMQConsumer>> resultHandler) |
void |
basicConsumer(String queue,
QueueOptions options,
Handler<AsyncResult<RabbitMQConsumer>> resultHandler)
Create a consumer with the given
options . |
void |
basicGet(String queue,
boolean autoAck,
Handler<AsyncResult<JsonObject>> resultHandler)
Retrieve a message from a queue using AMQP.Basic.Get
|
void |
basicNack(long deliveryTag,
boolean multiple,
boolean requeue,
Handler<AsyncResult<JsonObject>> resultHandler)
Reject one or several received messages.
|
void |
basicPublish(String exchange,
String routingKey,
JsonObject message,
Handler<AsyncResult<Void>> resultHandler)
Publish a message.
|
void |
basicQos(int prefetchCount,
boolean global,
Handler<AsyncResult<Void>> resultHandler)
Request a specific prefetchCount "quality of service" settings
for this channel.
|
void |
basicQos(int prefetchCount,
Handler<AsyncResult<Void>> resultHandler)
Request a specific prefetchCount "quality of service" settings
for this channel.
|
void |
basicQos(int prefetchSize,
int prefetchCount,
boolean global,
Handler<AsyncResult<Void>> resultHandler)
Request specific "quality of service" settings.
|
void |
confirmSelect(Handler<AsyncResult<Void>> resultHandler)
Enables publisher acknowledgements on this channel.
|
static RabbitMQClient |
create(Vertx vertx)
Create and return a client configured with the default options.
|
static RabbitMQClient |
create(Vertx vertx,
RabbitMQOptions config)
Create and return a client.
|
boolean |
equals(Object o) |
void |
exchangeBind(String destination,
String source,
String routingKey,
Handler<AsyncResult<Void>> resultHandler)
Bind an exchange to an exchange.
|
void |
exchangeBind(String destination,
String source,
String routingKey,
Map<String,Object> arguments,
Handler<AsyncResult<Void>> resultHandler)
Bind an exchange to an exchange.
|
void |
exchangeDeclare(String exchange,
String type,
boolean durable,
boolean autoDelete,
Handler<AsyncResult<Void>> resultHandler)
Declare an exchange.
|
void |
exchangeDeclare(String exchange,
String type,
boolean durable,
boolean autoDelete,
JsonObject config,
Handler<AsyncResult<Void>> resultHandler)
Declare an exchange with additional parameters such as dead lettering, an alternate exchange or TTL.
|
void |
exchangeDelete(String exchange,
Handler<AsyncResult<Void>> resultHandler)
Delete an exchange, without regard for whether it is in use or not.
|
void |
exchangeUnbind(String destination,
String source,
String routingKey,
Handler<AsyncResult<Void>> resultHandler)
Unbind an exchange from an exchange.
|
void |
exchangeUnbind(String destination,
String source,
String routingKey,
Map<String,Object> arguments,
Handler<AsyncResult<Void>> resultHandler)
Unbind an exchange from an exchange.
|
RabbitMQClient |
getDelegate() |
int |
hashCode() |
boolean |
isConnected()
Check if a connection is open
|
boolean |
isOpenChannel()
Check if a channel is open
|
void |
messageCount(String queue,
Handler<AsyncResult<Long>> resultHandler)
Returns the number of messages in a queue ready to be delivered.
|
static RabbitMQClient |
newInstance(RabbitMQClient arg) |
void |
queueBind(String queue,
String exchange,
String routingKey,
Handler<AsyncResult<Void>> resultHandler)
Bind a queue to an exchange
|
void |
queueBind(String queue,
String exchange,
String routingKey,
Map<String,Object> arguments,
Handler<AsyncResult<Void>> resultHandler)
Bind a queue to an exchange
|
void |
queueDeclare(String queue,
boolean durable,
boolean exclusive,
boolean autoDelete,
Handler<AsyncResult<JsonObject>> resultHandler)
Declare a queue
|
void |
queueDeclare(String queue,
boolean durable,
boolean exclusive,
boolean autoDelete,
JsonObject config,
Handler<AsyncResult<JsonObject>> resultHandler)
Declare a queue with config options
|
void |
queueDeclareAuto(Handler<AsyncResult<JsonObject>> resultHandler)
Actively declare a server-named exclusive, autodelete, non-durable queue.
|
void |
queueDelete(String queue,
Handler<AsyncResult<JsonObject>> resultHandler)
Delete a queue, without regard for whether it is in use or has messages on it
|
void |
queueDeleteIf(String queue,
boolean ifUnused,
boolean ifEmpty,
Handler<AsyncResult<JsonObject>> resultHandler)
Delete a queue
|
void |
queueUnbind(String queue,
String exchange,
String routingKey,
Handler<AsyncResult<Void>> resultHandler)
Unbind a queue from an exchange
|
void |
queueUnbind(String queue,
String exchange,
String routingKey,
Map<String,Object> arguments,
Handler<AsyncResult<Void>> resultHandler)
Unbind a queue from an exchange
|
Single<JsonObject> |
rxBasicAck(long deliveryTag,
boolean multiple)
Acknowledge one or several received messages.
|
Completable |
rxBasicCancel(String consumerTag)
Deprecated.
|
Single<String> |
rxBasicConsume(String queue,
String address)
Deprecated.
|
Single<String> |
rxBasicConsume(String queue,
String address,
boolean autoAck)
Deprecated.
|
Single<RabbitMQConsumer> |
rxBasicConsumer(String queue) |
Single<RabbitMQConsumer> |
rxBasicConsumer(String queue,
QueueOptions options)
Create a consumer with the given
options . |
Single<JsonObject> |
rxBasicGet(String queue,
boolean autoAck)
Retrieve a message from a queue using AMQP.Basic.Get
|
Single<JsonObject> |
rxBasicNack(long deliveryTag,
boolean multiple,
boolean requeue)
Reject one or several received messages.
|
Completable |
rxBasicPublish(String exchange,
String routingKey,
JsonObject message)
Publish a message.
|
Completable |
rxBasicQos(int prefetchCount)
Request a specific prefetchCount "quality of service" settings
for this channel.
|
Completable |
rxBasicQos(int prefetchCount,
boolean global)
Request a specific prefetchCount "quality of service" settings
for this channel.
|
Completable |
rxBasicQos(int prefetchSize,
int prefetchCount,
boolean global)
Request specific "quality of service" settings.
|
Completable |
rxConfirmSelect()
Enables publisher acknowledgements on this channel.
|
Completable |
rxExchangeBind(String destination,
String source,
String routingKey)
Bind an exchange to an exchange.
|
Completable |
rxExchangeBind(String destination,
String source,
String routingKey,
Map<String,Object> arguments)
Bind an exchange to an exchange.
|
Completable |
rxExchangeDeclare(String exchange,
String type,
boolean durable,
boolean autoDelete)
Declare an exchange.
|
Completable |
rxExchangeDeclare(String exchange,
String type,
boolean durable,
boolean autoDelete,
JsonObject config)
Declare an exchange with additional parameters such as dead lettering, an alternate exchange or TTL.
|
Completable |
rxExchangeDelete(String exchange)
Delete an exchange, without regard for whether it is in use or not.
|
Completable |
rxExchangeUnbind(String destination,
String source,
String routingKey)
Unbind an exchange from an exchange.
|
Completable |
rxExchangeUnbind(String destination,
String source,
String routingKey,
Map<String,Object> arguments)
Unbind an exchange from an exchange.
|
Single<Long> |
rxMessageCount(String queue)
Returns the number of messages in a queue ready to be delivered.
|
Completable |
rxQueueBind(String queue,
String exchange,
String routingKey)
Bind a queue to an exchange
|
Completable |
rxQueueBind(String queue,
String exchange,
String routingKey,
Map<String,Object> arguments)
Bind a queue to an exchange
|
Single<JsonObject> |
rxQueueDeclare(String queue,
boolean durable,
boolean exclusive,
boolean autoDelete)
Declare a queue
|
Single<JsonObject> |
rxQueueDeclare(String queue,
boolean durable,
boolean exclusive,
boolean autoDelete,
JsonObject config)
Declare a queue with config options
|
Single<JsonObject> |
rxQueueDeclareAuto()
Actively declare a server-named exclusive, autodelete, non-durable queue.
|
Single<JsonObject> |
rxQueueDelete(String queue)
Delete a queue, without regard for whether it is in use or has messages on it
|
Single<JsonObject> |
rxQueueDeleteIf(String queue,
boolean ifUnused,
boolean ifEmpty)
Delete a queue
|
Completable |
rxQueueUnbind(String queue,
String exchange,
String routingKey)
Unbind a queue from an exchange
|
Completable |
rxQueueUnbind(String queue,
String exchange,
String routingKey,
Map<String,Object> arguments)
Unbind a queue from an exchange
|
Completable |
rxStart()
Start the rabbitMQ client.
|
Completable |
rxStop()
Stop the rabbitMQ client.
|
Completable |
rxWaitForConfirms()
Wait until all messages published since the last call have been either ack'd or nack'd by the broker.
|
Completable |
rxWaitForConfirms(long timeout)
Wait until all messages published since the last call have been either ack'd or nack'd by the broker; or until timeout elapses.
|
void |
start(Handler<AsyncResult<Void>> resultHandler)
Start the rabbitMQ client.
|
void |
stop(Handler<AsyncResult<Void>> resultHandler)
Stop the rabbitMQ client.
|
String |
toString() |
void |
waitForConfirms(Handler<AsyncResult<Void>> resultHandler)
Wait until all messages published since the last call have been either ack'd or nack'd by the broker.
|
void |
waitForConfirms(long timeout,
Handler<AsyncResult<Void>> resultHandler)
Wait until all messages published since the last call have been either ack'd or nack'd by the broker; or until timeout elapses.
|
public static final io.vertx.lang.rx.TypeArg<RabbitMQClient> __TYPE_ARG
public RabbitMQClient(RabbitMQClient delegate)
public RabbitMQClient(Object delegate)
public RabbitMQClient getDelegate()
public static RabbitMQClient create(Vertx vertx)
vertx
- the vertx instancepublic static RabbitMQClient create(Vertx vertx, RabbitMQOptions config)
vertx
- the vertx instanceconfig
- the client configpublic void basicAck(long deliveryTag, boolean multiple, Handler<AsyncResult<JsonObject>> resultHandler)
deliveryTag
- multiple
- resultHandler
- public Single<JsonObject> rxBasicAck(long deliveryTag, boolean multiple)
deliveryTag
- multiple
- public void basicNack(long deliveryTag, boolean multiple, boolean requeue, Handler<AsyncResult<JsonObject>> resultHandler)
deliveryTag
- multiple
- requeue
- resultHandler
- public Single<JsonObject> rxBasicNack(long deliveryTag, boolean multiple, boolean requeue)
deliveryTag
- multiple
- requeue
- public void basicGet(String queue, boolean autoAck, Handler<AsyncResult<JsonObject>> resultHandler)
queue
- autoAck
- resultHandler
- public Single<JsonObject> rxBasicGet(String queue, boolean autoAck)
queue
- autoAck
- @Deprecated public void basicConsume(String queue, String address, Handler<AsyncResult<String>> resultHandler)
basicConsumer(java.lang.String, io.vertx.core.Handler<io.vertx.core.AsyncResult<io.vertx.reactivex.rabbitmq.RabbitMQConsumer>>)
instead
Start a non-nolocal, non-exclusive consumer, with auto acknowledgement and a server-generated consumerTag.
queue
- address
- resultHandler
- @Deprecated public Single<String> rxBasicConsume(String queue, String address)
basicConsumer(java.lang.String, io.vertx.core.Handler<io.vertx.core.AsyncResult<io.vertx.reactivex.rabbitmq.RabbitMQConsumer>>)
instead
Start a non-nolocal, non-exclusive consumer, with auto acknowledgement and a server-generated consumerTag.
queue
- address
- @Deprecated public void basicConsume(String queue, String address, boolean autoAck, Handler<AsyncResult<String>> resultHandler)
basicConsumer(java.lang.String, io.vertx.core.Handler<io.vertx.core.AsyncResult<io.vertx.reactivex.rabbitmq.RabbitMQConsumer>>)
instead
Start a non-nolocal, non-exclusive consumer, with a server-generated consumerTag.
queue
- address
- autoAck
- resultHandler
- @Deprecated public Single<String> rxBasicConsume(String queue, String address, boolean autoAck)
basicConsumer(java.lang.String, io.vertx.core.Handler<io.vertx.core.AsyncResult<io.vertx.reactivex.rabbitmq.RabbitMQConsumer>>)
instead
Start a non-nolocal, non-exclusive consumer, with a server-generated consumerTag.
queue
- address
- autoAck
- @Deprecated public void basicConsume(String queue, String address, boolean autoAck, Handler<AsyncResult<String>> resultHandler, Handler<Throwable> errorHandler)
basicConsumer(java.lang.String, io.vertx.core.Handler<io.vertx.core.AsyncResult<io.vertx.reactivex.rabbitmq.RabbitMQConsumer>>)
instead
Start a non-nolocal, non-exclusive consumer, with a server-generated consumerTag and error handler
queue
- address
- autoAck
- resultHandler
- errorHandler
- @Deprecated public void basicCancel(String consumerTag)
basicConsume(java.lang.String, java.lang.String, io.vertx.core.Handler<io.vertx.core.AsyncResult<java.lang.String>>)
method,
basicConsumer(java.lang.String, io.vertx.core.Handler<io.vertx.core.AsyncResult<io.vertx.reactivex.rabbitmq.RabbitMQConsumer>>)
and RabbitMQConsumer.cancel()
instead
This method should be called when you want to cancel consumption from a queue,
started by calling basicConsume(java.lang.String, java.lang.String, io.vertx.core.Handler<io.vertx.core.AsyncResult<java.lang.String>>)
.
consumerTag
- @Deprecated public void basicCancel(String consumerTag, Handler<AsyncResult<Void>> resultHandler)
basicConsume(java.lang.String, java.lang.String, io.vertx.core.Handler<io.vertx.core.AsyncResult<java.lang.String>>)
method,
basicConsumer(java.lang.String, io.vertx.core.Handler<io.vertx.core.AsyncResult<io.vertx.reactivex.rabbitmq.RabbitMQConsumer>>)
and RabbitMQConsumer.cancel()
instead
This method should be called when you want to cancel consumption from a queue,
started by calling basicConsume(java.lang.String, java.lang.String, io.vertx.core.Handler<io.vertx.core.AsyncResult<java.lang.String>>)
.
consumerTag
- resultHandler
- @Deprecated public Completable rxBasicCancel(String consumerTag)
basicConsume(java.lang.String, java.lang.String, io.vertx.core.Handler<io.vertx.core.AsyncResult<java.lang.String>>)
method,
basicConsumer(java.lang.String, io.vertx.core.Handler<io.vertx.core.AsyncResult<io.vertx.reactivex.rabbitmq.RabbitMQConsumer>>)
and RabbitMQConsumer.cancel()
instead
This method should be called when you want to cancel consumption from a queue,
started by calling basicConsume(java.lang.String, java.lang.String, io.vertx.core.Handler<io.vertx.core.AsyncResult<java.lang.String>>)
.
consumerTag
- public void basicConsumer(String queue, Handler<AsyncResult<RabbitMQConsumer>> resultHandler)
queue
- resultHandler
- public Single<RabbitMQConsumer> rxBasicConsumer(String queue)
queue
- public void basicConsumer(String queue, QueueOptions options, Handler<AsyncResult<RabbitMQConsumer>> resultHandler)
options
.queue
- the name of a queueoptions
- options for queueresultHandler
- a handler through which you can find out the operation status; if the operation succeeds you can begin to receive messages through an instance of RabbitMQConsumer
public Single<RabbitMQConsumer> rxBasicConsumer(String queue, QueueOptions options)
options
.queue
- the name of a queueoptions
- options for queuepublic void basicPublish(String exchange, String routingKey, JsonObject message, Handler<AsyncResult<Void>> resultHandler)
exchange
- routingKey
- message
- resultHandler
- public Completable rxBasicPublish(String exchange, String routingKey, JsonObject message)
exchange
- routingKey
- message
- public void confirmSelect(Handler<AsyncResult<Void>> resultHandler)
resultHandler
- public Completable rxConfirmSelect()
public void waitForConfirms(Handler<AsyncResult<Void>> resultHandler)
resultHandler
- public Completable rxWaitForConfirms()
public void waitForConfirms(long timeout, Handler<AsyncResult<Void>> resultHandler)
timeout
- resultHandler
- public Completable rxWaitForConfirms(long timeout)
timeout
- public void basicQos(int prefetchCount, Handler<AsyncResult<Void>> resultHandler)
prefetchCount
- maximum number of messages that the server will deliver, 0 if unlimitedresultHandler
- handler called when operation is done with a result of the operationpublic Completable rxBasicQos(int prefetchCount)
prefetchCount
- maximum number of messages that the server will deliver, 0 if unlimitedpublic void basicQos(int prefetchCount, boolean global, Handler<AsyncResult<Void>> resultHandler)
prefetchCount
- maximum number of messages that the server will deliver, 0 if unlimitedglobal
- true if the settings should be applied to the entire channel rather than each consumerresultHandler
- handler called when operation is done with a result of the operationpublic Completable rxBasicQos(int prefetchCount, boolean global)
prefetchCount
- maximum number of messages that the server will deliver, 0 if unlimitedglobal
- true if the settings should be applied to the entire channel rather than each consumerpublic void basicQos(int prefetchSize, int prefetchCount, boolean global, Handler<AsyncResult<Void>> resultHandler)
prefetchSize
- maximum amount of content (measured in octets) that the server will deliver, 0 if unlimitedprefetchCount
- maximum number of messages that the server will deliver, 0 if unlimitedglobal
- true if the settings should be applied to the entire channel rather than each consumerresultHandler
- handler called when operation is done with a result of the operationpublic Completable rxBasicQos(int prefetchSize, int prefetchCount, boolean global)
prefetchSize
- maximum amount of content (measured in octets) that the server will deliver, 0 if unlimitedprefetchCount
- maximum number of messages that the server will deliver, 0 if unlimitedglobal
- true if the settings should be applied to the entire channel rather than each consumerpublic void exchangeDeclare(String exchange, String type, boolean durable, boolean autoDelete, Handler<AsyncResult<Void>> resultHandler)
exchange
- type
- durable
- autoDelete
- resultHandler
- public Completable rxExchangeDeclare(String exchange, String type, boolean durable, boolean autoDelete)
exchange
- type
- durable
- autoDelete
- public void exchangeDeclare(String exchange, String type, boolean durable, boolean autoDelete, JsonObject config, Handler<AsyncResult<Void>> resultHandler)
exchange
- type
- durable
- autoDelete
- config
- resultHandler
- public Completable rxExchangeDeclare(String exchange, String type, boolean durable, boolean autoDelete, JsonObject config)
exchange
- type
- durable
- autoDelete
- config
- public void exchangeDelete(String exchange, Handler<AsyncResult<Void>> resultHandler)
exchange
- resultHandler
- public Completable rxExchangeDelete(String exchange)
exchange
- public void exchangeBind(String destination, String source, String routingKey, Handler<AsyncResult<Void>> resultHandler)
destination
- source
- routingKey
- resultHandler
- public Completable rxExchangeBind(String destination, String source, String routingKey)
destination
- source
- routingKey
- public void exchangeBind(String destination, String source, String routingKey, Map<String,Object> arguments, Handler<AsyncResult<Void>> resultHandler)
destination
- source
- routingKey
- arguments
- resultHandler
- public Completable rxExchangeBind(String destination, String source, String routingKey, Map<String,Object> arguments)
destination
- source
- routingKey
- arguments
- public void exchangeUnbind(String destination, String source, String routingKey, Handler<AsyncResult<Void>> resultHandler)
destination
- source
- routingKey
- resultHandler
- public Completable rxExchangeUnbind(String destination, String source, String routingKey)
destination
- source
- routingKey
- public void exchangeUnbind(String destination, String source, String routingKey, Map<String,Object> arguments, Handler<AsyncResult<Void>> resultHandler)
destination
- source
- routingKey
- arguments
- resultHandler
- public Completable rxExchangeUnbind(String destination, String source, String routingKey, Map<String,Object> arguments)
destination
- source
- routingKey
- arguments
- public void queueDeclareAuto(Handler<AsyncResult<JsonObject>> resultHandler)
resultHandler
- public Single<JsonObject> rxQueueDeclareAuto()
public void queueDeclare(String queue, boolean durable, boolean exclusive, boolean autoDelete, Handler<AsyncResult<JsonObject>> resultHandler)
queue
- durable
- exclusive
- autoDelete
- resultHandler
- public Single<JsonObject> rxQueueDeclare(String queue, boolean durable, boolean exclusive, boolean autoDelete)
queue
- durable
- exclusive
- autoDelete
- public void queueDeclare(String queue, boolean durable, boolean exclusive, boolean autoDelete, JsonObject config, Handler<AsyncResult<JsonObject>> resultHandler)
queue
- durable
- exclusive
- autoDelete
- config
- resultHandler
- public Single<JsonObject> rxQueueDeclare(String queue, boolean durable, boolean exclusive, boolean autoDelete, JsonObject config)
queue
- durable
- exclusive
- autoDelete
- config
- public void queueDelete(String queue, Handler<AsyncResult<JsonObject>> resultHandler)
queue
- resultHandler
- public Single<JsonObject> rxQueueDelete(String queue)
queue
- public void queueDeleteIf(String queue, boolean ifUnused, boolean ifEmpty, Handler<AsyncResult<JsonObject>> resultHandler)
queue
- ifUnused
- ifEmpty
- resultHandler
- public Single<JsonObject> rxQueueDeleteIf(String queue, boolean ifUnused, boolean ifEmpty)
queue
- ifUnused
- ifEmpty
- public void queueBind(String queue, String exchange, String routingKey, Handler<AsyncResult<Void>> resultHandler)
queue
- exchange
- routingKey
- resultHandler
- public Completable rxQueueBind(String queue, String exchange, String routingKey)
queue
- exchange
- routingKey
- public void queueBind(String queue, String exchange, String routingKey, Map<String,Object> arguments, Handler<AsyncResult<Void>> resultHandler)
queue
- exchange
- routingKey
- arguments
- resultHandler
- public Completable rxQueueBind(String queue, String exchange, String routingKey, Map<String,Object> arguments)
queue
- exchange
- routingKey
- arguments
- public void queueUnbind(String queue, String exchange, String routingKey, Handler<AsyncResult<Void>> resultHandler)
queue
- exchange
- routingKey
- resultHandler
- public Completable rxQueueUnbind(String queue, String exchange, String routingKey)
queue
- exchange
- routingKey
- public void queueUnbind(String queue, String exchange, String routingKey, Map<String,Object> arguments, Handler<AsyncResult<Void>> resultHandler)
queue
- exchange
- routingKey
- arguments
- resultHandler
- public Completable rxQueueUnbind(String queue, String exchange, String routingKey, Map<String,Object> arguments)
queue
- exchange
- routingKey
- arguments
- public void messageCount(String queue, Handler<AsyncResult<Long>> resultHandler)
queue
- resultHandler
- public Single<Long> rxMessageCount(String queue)
queue
- public void start(Handler<AsyncResult<Void>> resultHandler)
resultHandler
- public Completable rxStart()
public void stop(Handler<AsyncResult<Void>> resultHandler)
resultHandler
- public Completable rxStop()
public boolean isConnected()
public boolean isOpenChannel()
public static RabbitMQClient newInstance(RabbitMQClient arg)
Copyright © 2023 Eclipse. All rights reserved.