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 |
addConfirmListener(int maxQueueSize)
Add a Confirm Listener to the channel.
|
void |
addConfirmListener(int maxQueueSize,
Handler<AsyncResult<ReadStream<RabbitMQConfirmation>>> resultHandler)
Add a Confirm Listener to the channel.
|
void |
basicAck(long deliveryTag,
boolean multiple)
Acknowledge one or several received messages.
|
void |
basicAck(long deliveryTag,
boolean multiple,
Handler<AsyncResult<Void>> resultHandler)
Acknowledge one or several received messages.
|
void |
basicConsumer(String queue) |
void |
basicConsumer(String queue,
Handler<AsyncResult<RabbitMQConsumer>> resultHandler) |
void |
basicConsumer(String queue,
QueueOptions options)
Create a consumer with the given
options . |
void |
basicConsumer(String queue,
QueueOptions options,
Handler<AsyncResult<RabbitMQConsumer>> resultHandler)
Create a consumer with the given
options . |
void |
basicGet(String queue,
boolean autoAck)
Retrieve a message from a queue using AMQP.Basic.Get
|
void |
basicGet(String queue,
boolean autoAck,
Handler<AsyncResult<RabbitMQMessage>> resultHandler)
Retrieve a message from a queue using AMQP.Basic.Get
|
void |
basicNack(long deliveryTag,
boolean multiple,
boolean requeue)
Reject one or several received messages.
|
void |
basicNack(long deliveryTag,
boolean multiple,
boolean requeue,
Handler<AsyncResult<Void>> resultHandler)
Reject one or several received messages.
|
void |
basicPublish(String exchange,
String routingKey,
com.rabbitmq.client.BasicProperties properties,
Buffer body)
Publish a message.
|
void |
basicPublish(String exchange,
String routingKey,
com.rabbitmq.client.BasicProperties properties,
Buffer body,
Handler<AsyncResult<Void>> resultHandler)
Publish a message.
|
void |
basicPublish(String exchange,
String routingKey,
Buffer body)
Publish a message.
|
void |
basicPublish(String exchange,
String routingKey,
Buffer body,
Handler<AsyncResult<Void>> resultHandler)
Publish a message.
|
void |
basicPublishWithDeliveryTag(String exchange,
String routingKey,
com.rabbitmq.client.BasicProperties properties,
Buffer body,
Handler<Long> deliveryTagHandler)
Publish a message.
|
void |
basicPublishWithDeliveryTag(String exchange,
String routingKey,
com.rabbitmq.client.BasicProperties properties,
Buffer body,
Handler<Long> deliveryTagHandler,
Handler<AsyncResult<Void>> resultHandler)
Publish a message.
|
void |
basicQos(int prefetchCount)
Request a specific prefetchCount "quality of service" settings
for this channel.
|
void |
basicQos(int prefetchCount,
boolean global)
Request a specific prefetchCount "quality of service" settings
for this channel.
|
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)
Request specific "quality of service" settings.
|
void |
basicQos(int prefetchSize,
int prefetchCount,
boolean global,
Handler<AsyncResult<Void>> resultHandler)
Request specific "quality of service" settings.
|
void |
confirmSelect()
Enables publisher acknowledgements on this channel.
|
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)
Bind an exchange to an exchange.
|
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)
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)
Declare 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)
Declare an exchange with additional parameters such as dead lettering, an alternate exchange or TTL.
|
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)
Delete an exchange, without regard for whether it is in use or not.
|
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)
Unbind an exchange from an exchange.
|
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)
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)
Returns the number of messages in a queue ready to be delivered.
|
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)
Bind a queue to an exchange
|
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)
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)
Declare a queue
|
void |
queueDeclare(String queue,
boolean durable,
boolean exclusive,
boolean autoDelete,
Handler<AsyncResult<com.rabbitmq.client.AMQP.Queue.DeclareOk>> resultHandler)
Declare a queue
|
void |
queueDeclare(String queue,
boolean durable,
boolean exclusive,
boolean autoDelete,
JsonObject config)
Declare a queue with config options
|
void |
queueDeclare(String queue,
boolean durable,
boolean exclusive,
boolean autoDelete,
JsonObject config,
Handler<AsyncResult<com.rabbitmq.client.AMQP.Queue.DeclareOk>> resultHandler)
Declare a queue with config options
|
void |
queueDeclareAuto()
Actively declare a server-named exclusive, autodelete, non-durable queue.
|
void |
queueDeclareAuto(Handler<AsyncResult<JsonObject>> resultHandler)
Actively declare a server-named exclusive, autodelete, non-durable queue.
|
void |
queueDelete(String queue)
Delete a queue, without regard for whether it is in use or has messages on it
|
void |
queueDelete(String queue,
Handler<AsyncResult<com.rabbitmq.client.AMQP.Queue.DeleteOk>> 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)
Delete a queue
|
void |
queueDeleteIf(String queue,
boolean ifUnused,
boolean ifEmpty,
Handler<AsyncResult<com.rabbitmq.client.AMQP.Queue.DeleteOk>> resultHandler)
Delete a queue
|
void |
queueUnbind(String queue,
String exchange,
String routingKey)
Unbind a queue from an exchange
|
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)
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
|
void |
restartConnect(int attempts)
restart the rabbitMQ connect.
|
void |
restartConnect(int attempts,
Handler<AsyncResult<Void>> resultHandler)
restart the rabbitMQ connect.
|
Single<ReadStream<RabbitMQConfirmation>> |
rxAddConfirmListener(int maxQueueSize)
Add a Confirm Listener to the channel.
|
Single<Void> |
rxBasicAck(long deliveryTag,
boolean multiple)
Acknowledge one or several received messages.
|
Single<RabbitMQConsumer> |
rxBasicConsumer(String queue) |
Single<RabbitMQConsumer> |
rxBasicConsumer(String queue,
QueueOptions options)
Create a consumer with the given
options . |
Single<RabbitMQMessage> |
rxBasicGet(String queue,
boolean autoAck)
Retrieve a message from a queue using AMQP.Basic.Get
|
Single<Void> |
rxBasicNack(long deliveryTag,
boolean multiple,
boolean requeue)
Reject one or several received messages.
|
Single<Void> |
rxBasicPublish(String exchange,
String routingKey,
com.rabbitmq.client.BasicProperties properties,
Buffer body)
Publish a message.
|
Single<Void> |
rxBasicPublish(String exchange,
String routingKey,
Buffer body)
Publish a message.
|
Single<Void> |
rxBasicPublishWithDeliveryTag(String exchange,
String routingKey,
com.rabbitmq.client.BasicProperties properties,
Buffer body,
Handler<Long> deliveryTagHandler)
Publish a message.
|
Single<Void> |
rxBasicQos(int prefetchCount)
Request a specific prefetchCount "quality of service" settings
for this channel.
|
Single<Void> |
rxBasicQos(int prefetchCount,
boolean global)
Request a specific prefetchCount "quality of service" settings
for this channel.
|
Single<Void> |
rxBasicQos(int prefetchSize,
int prefetchCount,
boolean global)
Request specific "quality of service" settings.
|
Single<Void> |
rxConfirmSelect()
Enables publisher acknowledgements on this channel.
|
Single<Void> |
rxExchangeBind(String destination,
String source,
String routingKey)
Bind an exchange to an exchange.
|
Single<Void> |
rxExchangeBind(String destination,
String source,
String routingKey,
Map<String,Object> arguments)
Bind an exchange to an exchange.
|
Single<Void> |
rxExchangeDeclare(String exchange,
String type,
boolean durable,
boolean autoDelete)
Declare an exchange.
|
Single<Void> |
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.
|
Single<Void> |
rxExchangeDelete(String exchange)
Delete an exchange, without regard for whether it is in use or not.
|
Single<Void> |
rxExchangeUnbind(String destination,
String source,
String routingKey)
Unbind an exchange from an exchange.
|
Single<Void> |
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.
|
Single<Void> |
rxQueueBind(String queue,
String exchange,
String routingKey)
Bind a queue to an exchange
|
Single<Void> |
rxQueueBind(String queue,
String exchange,
String routingKey,
Map<String,Object> arguments)
Bind a queue to an exchange
|
Single<com.rabbitmq.client.AMQP.Queue.DeclareOk> |
rxQueueDeclare(String queue,
boolean durable,
boolean exclusive,
boolean autoDelete)
Declare a queue
|
Single<com.rabbitmq.client.AMQP.Queue.DeclareOk> |
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<com.rabbitmq.client.AMQP.Queue.DeleteOk> |
rxQueueDelete(String queue)
Delete a queue, without regard for whether it is in use or has messages on it
|
Single<com.rabbitmq.client.AMQP.Queue.DeleteOk> |
rxQueueDeleteIf(String queue,
boolean ifUnused,
boolean ifEmpty)
Delete a queue
|
Single<Void> |
rxQueueUnbind(String queue,
String exchange,
String routingKey)
Unbind a queue from an exchange
|
Single<Void> |
rxQueueUnbind(String queue,
String exchange,
String routingKey,
Map<String,Object> arguments)
Unbind a queue from an exchange
|
Single<Void> |
rxRestartConnect(int attempts)
restart the rabbitMQ connect.
|
Single<Void> |
rxStart()
Start the rabbitMQ client.
|
Single<Void> |
rxStop()
Stop the rabbitMQ client.
|
Single<Void> |
rxWaitForConfirms()
Wait until all messages published since the last call have been either ack'd or nack'd by the broker.
|
Single<Void> |
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()
Start the rabbitMQ client.
|
void |
start(Handler<AsyncResult<Void>> resultHandler)
Start the rabbitMQ client.
|
void |
stop()
Stop the rabbitMQ client.
|
void |
stop(Handler<AsyncResult<Void>> resultHandler)
Stop the rabbitMQ client.
|
String |
toString() |
void |
waitForConfirms()
Wait until all messages published since the last call have been either ack'd or nack'd by the broker.
|
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)
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 |
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<Void>> resultHandler)
deliveryTag
- multiple
- resultHandler
- public void basicAck(long deliveryTag, boolean multiple)
deliveryTag
- multiple
- public Single<Void> rxBasicAck(long deliveryTag, boolean multiple)
deliveryTag
- multiple
- public void basicNack(long deliveryTag, boolean multiple, boolean requeue, Handler<AsyncResult<Void>> resultHandler)
deliveryTag
- multiple
- requeue
- resultHandler
- public void basicNack(long deliveryTag, boolean multiple, boolean requeue)
deliveryTag
- multiple
- requeue
- public Single<Void> rxBasicNack(long deliveryTag, boolean multiple, boolean requeue)
deliveryTag
- multiple
- requeue
- public void basicGet(String queue, boolean autoAck, Handler<AsyncResult<RabbitMQMessage>> resultHandler)
queue
- autoAck
- resultHandler
- public void basicGet(String queue, boolean autoAck)
queue
- autoAck
- public Single<RabbitMQMessage> rxBasicGet(String queue, boolean autoAck)
queue
- autoAck
- public void basicConsumer(String queue, Handler<AsyncResult<RabbitMQConsumer>> resultHandler)
queue
- resultHandler
- public void basicConsumer(String queue)
queue
- 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 void basicConsumer(String queue, QueueOptions options)
options
.queue
- the name of a queueoptions
- options for queuepublic Single<RabbitMQConsumer> rxBasicConsumer(String queue, QueueOptions options)
options
.queue
- the name of a queueoptions
- options for queuepublic void basicPublish(String exchange, String routingKey, Buffer body, Handler<AsyncResult<Void>> resultHandler)
exchange
- routingKey
- body
- resultHandler
- public void basicPublish(String exchange, String routingKey, Buffer body)
exchange
- routingKey
- body
- public Single<Void> rxBasicPublish(String exchange, String routingKey, Buffer body)
exchange
- routingKey
- body
- public void addConfirmListener(int maxQueueSize, Handler<AsyncResult<ReadStream<RabbitMQConfirmation>>> resultHandler)
maxQueueSize
- maximum size of the queue of confirmationsresultHandler
- a handler through which you can find out the operation status; if the operation succeeds you can begin to receive confirmations through an instance ofpublic void addConfirmListener(int maxQueueSize)
maxQueueSize
- maximum size of the queue of confirmationspublic Single<ReadStream<RabbitMQConfirmation>> rxAddConfirmListener(int maxQueueSize)
maxQueueSize
- maximum size of the queue of confirmationspublic void confirmSelect(Handler<AsyncResult<Void>> resultHandler)
resultHandler
- public void confirmSelect()
public Single<Void> rxConfirmSelect()
public void waitForConfirms(Handler<AsyncResult<Void>> resultHandler)
resultHandler
- public void waitForConfirms()
public Single<Void> rxWaitForConfirms()
public void waitForConfirms(long timeout, Handler<AsyncResult<Void>> resultHandler)
timeout
- resultHandler
- public void waitForConfirms(long timeout)
timeout
- public Single<Void> 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 void basicQos(int prefetchCount)
prefetchCount
- maximum number of messages that the server will deliver, 0 if unlimitedpublic Single<Void> 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 void basicQos(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 Single<Void> 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 void basicQos(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 Single<Void> 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 void exchangeDeclare(String exchange, String type, boolean durable, boolean autoDelete)
exchange
- type
- durable
- autoDelete
- public Single<Void> 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 void exchangeDeclare(String exchange, String type, boolean durable, boolean autoDelete, JsonObject config)
exchange
- type
- durable
- autoDelete
- config
- public Single<Void> 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 void exchangeDelete(String exchange)
exchange
- public Single<Void> rxExchangeDelete(String exchange)
exchange
- public void exchangeBind(String destination, String source, String routingKey, Handler<AsyncResult<Void>> resultHandler)
destination
- source
- routingKey
- resultHandler
- public void exchangeBind(String destination, String source, String routingKey)
destination
- source
- routingKey
- public Single<Void> 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 void exchangeBind(String destination, String source, String routingKey, Map<String,Object> arguments)
destination
- source
- routingKey
- arguments
- public Single<Void> 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 void exchangeUnbind(String destination, String source, String routingKey)
destination
- source
- routingKey
- public Single<Void> 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 void exchangeUnbind(String destination, String source, String routingKey, Map<String,Object> arguments)
destination
- source
- routingKey
- arguments
- public Single<Void> rxExchangeUnbind(String destination, String source, String routingKey, Map<String,Object> arguments)
destination
- source
- routingKey
- arguments
- public void queueDeclareAuto(Handler<AsyncResult<JsonObject>> resultHandler)
resultHandler
- public void queueDeclareAuto()
public Single<JsonObject> rxQueueDeclareAuto()
public void queueBind(String queue, String exchange, String routingKey, Handler<AsyncResult<Void>> resultHandler)
queue
- exchange
- routingKey
- resultHandler
- public void queueBind(String queue, String exchange, String routingKey)
queue
- exchange
- routingKey
- public Single<Void> 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 void queueBind(String queue, String exchange, String routingKey, Map<String,Object> arguments)
queue
- exchange
- routingKey
- arguments
- public Single<Void> 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 void queueUnbind(String queue, String exchange, String routingKey)
queue
- exchange
- routingKey
- public Single<Void> 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 void queueUnbind(String queue, String exchange, String routingKey, Map<String,Object> arguments)
queue
- exchange
- routingKey
- arguments
- public Single<Void> 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 void messageCount(String queue)
queue
- public Single<Long> rxMessageCount(String queue)
queue
- public void start(Handler<AsyncResult<Void>> resultHandler)
resultHandler
- public void start()
public Single<Void> rxStart()
public void stop(Handler<AsyncResult<Void>> resultHandler)
resultHandler
- public void stop()
public Single<Void> rxStop()
public boolean isConnected()
public void restartConnect(int attempts, Handler<AsyncResult<Void>> resultHandler)
attempts
- number of attemptsresultHandler
- handler called when operation is done with a result of the operationpublic void restartConnect(int attempts)
attempts
- number of attemptspublic Single<Void> rxRestartConnect(int attempts)
attempts
- number of attemptspublic boolean isOpenChannel()
public void basicPublish(String exchange, String routingKey, com.rabbitmq.client.BasicProperties properties, Buffer body, Handler<AsyncResult<Void>> resultHandler)
exchange
- routingKey
- properties
- body
- resultHandler
- public void basicPublish(String exchange, String routingKey, com.rabbitmq.client.BasicProperties properties, Buffer body)
exchange
- routingKey
- properties
- body
- public Single<Void> rxBasicPublish(String exchange, String routingKey, com.rabbitmq.client.BasicProperties properties, Buffer body)
exchange
- routingKey
- properties
- body
- public void basicPublishWithDeliveryTag(String exchange, String routingKey, com.rabbitmq.client.BasicProperties properties, Buffer body, Handler<Long> deliveryTagHandler, Handler<AsyncResult<Void>> resultHandler)
exchange
- routingKey
- properties
- body
- deliveryTagHandler
- callback to capture the deliveryTag for this message. Note that this will be called synchronously in the context of the client before the result is known.resultHandler
- public void basicPublishWithDeliveryTag(String exchange, String routingKey, com.rabbitmq.client.BasicProperties properties, Buffer body, Handler<Long> deliveryTagHandler)
exchange
- routingKey
- properties
- body
- deliveryTagHandler
- callback to capture the deliveryTag for this message. Note that this will be called synchronously in the context of the client before the result is known.public Single<Void> rxBasicPublishWithDeliveryTag(String exchange, String routingKey, com.rabbitmq.client.BasicProperties properties, Buffer body, Handler<Long> deliveryTagHandler)
exchange
- routingKey
- properties
- body
- deliveryTagHandler
- callback to capture the deliveryTag for this message. Note that this will be called synchronously in the context of the client before the result is known.public void queueDeclare(String queue, boolean durable, boolean exclusive, boolean autoDelete, Handler<AsyncResult<com.rabbitmq.client.AMQP.Queue.DeclareOk>> resultHandler)
queue
- durable
- exclusive
- autoDelete
- resultHandler
- public void queueDeclare(String queue, boolean durable, boolean exclusive, boolean autoDelete)
queue
- durable
- exclusive
- autoDelete
- public Single<com.rabbitmq.client.AMQP.Queue.DeclareOk> 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<com.rabbitmq.client.AMQP.Queue.DeclareOk>> resultHandler)
queue
- durable
- exclusive
- autoDelete
- config
- resultHandler
- public void queueDeclare(String queue, boolean durable, boolean exclusive, boolean autoDelete, JsonObject config)
queue
- durable
- exclusive
- autoDelete
- config
- public Single<com.rabbitmq.client.AMQP.Queue.DeclareOk> rxQueueDeclare(String queue, boolean durable, boolean exclusive, boolean autoDelete, JsonObject config)
queue
- durable
- exclusive
- autoDelete
- config
- public void queueDelete(String queue, Handler<AsyncResult<com.rabbitmq.client.AMQP.Queue.DeleteOk>> resultHandler)
queue
- resultHandler
- public void queueDelete(String queue)
queue
- public Single<com.rabbitmq.client.AMQP.Queue.DeleteOk> rxQueueDelete(String queue)
queue
- public void queueDeleteIf(String queue, boolean ifUnused, boolean ifEmpty, Handler<AsyncResult<com.rabbitmq.client.AMQP.Queue.DeleteOk>> resultHandler)
queue
- ifUnused
- ifEmpty
- resultHandler
- public void queueDeleteIf(String queue, boolean ifUnused, boolean ifEmpty)
queue
- ifUnused
- ifEmpty
- public Single<com.rabbitmq.client.AMQP.Queue.DeleteOk> rxQueueDeleteIf(String queue, boolean ifUnused, boolean ifEmpty)
queue
- ifUnused
- ifEmpty
- public static RabbitMQClient newInstance(RabbitMQClient arg)
Copyright © 2023 Eclipse. All rights reserved.