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 |
---|---|
Single<ReadStream<RabbitMQConfirmation>> |
addConfirmListener(int maxQueueSize)
Add a Confirm Listener to the channel.
|
Completable |
basicAck(long deliveryTag,
boolean multiple)
Acknowledge one or several received messages.
|
Single<RabbitMQConsumer> |
basicConsumer(String queue) |
Single<RabbitMQConsumer> |
basicConsumer(String queue,
QueueOptions options)
Create a consumer with the given
options . |
Single<RabbitMQMessage> |
basicGet(String queue,
boolean autoAck)
Retrieve a message from a queue using AMQP.Basic.Get
|
Completable |
basicNack(long deliveryTag,
boolean multiple,
boolean requeue)
Reject one or several received messages.
|
Completable |
basicPublish(String exchange,
String routingKey,
com.rabbitmq.client.BasicProperties properties,
Buffer body)
Publish a message.
|
Completable |
basicPublish(String exchange,
String routingKey,
Buffer body)
Publish a message.
|
Completable |
basicPublishWithDeliveryTag(String exchange,
String routingKey,
com.rabbitmq.client.BasicProperties properties,
Buffer body,
Handler<Long> deliveryTagHandler)
Publish a message.
|
Completable |
basicQos(int prefetchCount)
Request a specific prefetchCount "quality of service" settings
for this channel.
|
Completable |
basicQos(int prefetchCount,
boolean global)
Request a specific prefetchCount "quality of service" settings
for this channel.
|
Completable |
basicQos(int prefetchSize,
int prefetchCount,
boolean global)
Request specific "quality of service" settings.
|
Completable |
confirmSelect()
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) |
Completable |
exchangeBind(String destination,
String source,
String routingKey)
Bind an exchange to an exchange.
|
Completable |
exchangeBind(String destination,
String source,
String routingKey,
Map<String,Object> arguments)
Bind an exchange to an exchange.
|
Completable |
exchangeDeclare(String exchange,
String type,
boolean durable,
boolean autoDelete)
Declare an exchange.
|
Completable |
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.
|
Completable |
exchangeDelete(String exchange)
Delete an exchange, without regard for whether it is in use or not.
|
Completable |
exchangeUnbind(String destination,
String source,
String routingKey)
Unbind an exchange from an exchange.
|
Completable |
exchangeUnbind(String destination,
String source,
String routingKey,
Map<String,Object> arguments)
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
|
Single<Long> |
messageCount(String queue)
Returns the number of messages in a queue ready to be delivered.
|
static RabbitMQClient |
newInstance(RabbitMQClient arg) |
Completable |
queueBind(String queue,
String exchange,
String routingKey)
Bind a queue to an exchange
|
Completable |
queueBind(String queue,
String exchange,
String routingKey,
Map<String,Object> arguments)
Bind a queue to an exchange
|
Single<com.rabbitmq.client.AMQP.Queue.DeclareOk> |
queueDeclare(String queue,
boolean durable,
boolean exclusive,
boolean autoDelete)
Declare a queue
|
Single<com.rabbitmq.client.AMQP.Queue.DeclareOk> |
queueDeclare(String queue,
boolean durable,
boolean exclusive,
boolean autoDelete,
JsonObject config)
Declare a queue with config options
|
Single<JsonObject> |
queueDeclareAuto()
Actively declare a server-named exclusive, autodelete, non-durable queue.
|
Single<com.rabbitmq.client.AMQP.Queue.DeleteOk> |
queueDelete(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> |
queueDeleteIf(String queue,
boolean ifUnused,
boolean ifEmpty)
Delete a queue
|
Completable |
queueUnbind(String queue,
String exchange,
String routingKey)
Unbind a queue from an exchange
|
Completable |
queueUnbind(String queue,
String exchange,
String routingKey,
Map<String,Object> arguments)
Unbind a queue from an exchange
|
Completable |
restartConnect(int attempts)
restart the rabbitMQ connect.
|
Single<ReadStream<RabbitMQConfirmation>> |
rxAddConfirmListener(int maxQueueSize)
Add a Confirm Listener to the channel.
|
Completable |
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
|
Completable |
rxBasicNack(long deliveryTag,
boolean multiple,
boolean requeue)
Reject one or several received messages.
|
Completable |
rxBasicPublish(String exchange,
String routingKey,
com.rabbitmq.client.BasicProperties properties,
Buffer body)
Publish a message.
|
Completable |
rxBasicPublish(String exchange,
String routingKey,
Buffer body)
Publish a message.
|
Completable |
rxBasicPublishWithDeliveryTag(String exchange,
String routingKey,
com.rabbitmq.client.BasicProperties properties,
Buffer body,
Handler<Long> deliveryTagHandler)
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<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
|
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 |
rxRestartConnect(int attempts)
restart the rabbitMQ connect.
|
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.
|
Completable |
start()
Start the rabbitMQ client.
|
Completable |
stop()
Stop the rabbitMQ client.
|
String |
toString() |
Completable |
waitForConfirms()
Wait until all messages published since the last call have been either ack'd or nack'd by the broker.
|
Completable |
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.
|
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 Completable basicAck(long deliveryTag, boolean multiple)
deliveryTag
- multiple
- public Completable rxBasicAck(long deliveryTag, boolean multiple)
deliveryTag
- multiple
- public Completable basicNack(long deliveryTag, boolean multiple, boolean requeue)
deliveryTag
- multiple
- requeue
- public Completable rxBasicNack(long deliveryTag, boolean multiple, boolean requeue)
deliveryTag
- multiple
- requeue
- public Single<RabbitMQMessage> basicGet(String queue, boolean autoAck)
queue
- autoAck
- public Single<RabbitMQMessage> rxBasicGet(String queue, boolean autoAck)
queue
- autoAck
- public Single<RabbitMQConsumer> basicConsumer(String queue)
queue
- public Single<RabbitMQConsumer> rxBasicConsumer(String queue)
queue
- public Single<RabbitMQConsumer> 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 Completable basicPublish(String exchange, String routingKey, Buffer body)
exchange
- routingKey
- body
- public Completable rxBasicPublish(String exchange, String routingKey, Buffer body)
exchange
- routingKey
- body
- public Single<ReadStream<RabbitMQConfirmation>> 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 Completable confirmSelect()
public Completable rxConfirmSelect()
public Completable waitForConfirms()
public Completable rxWaitForConfirms()
public Completable waitForConfirms(long timeout)
timeout
- public Completable rxWaitForConfirms(long timeout)
timeout
- public Completable basicQos(int prefetchCount)
prefetchCount
- maximum number of messages that the server will deliver, 0 if unlimitedpublic Completable rxBasicQos(int prefetchCount)
prefetchCount
- maximum number of messages that the server will deliver, 0 if unlimitedpublic Completable 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 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 Completable 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 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 Completable exchangeDeclare(String exchange, String type, boolean durable, boolean autoDelete)
exchange
- type
- durable
- autoDelete
- public Completable rxExchangeDeclare(String exchange, String type, boolean durable, boolean autoDelete)
exchange
- type
- durable
- autoDelete
- public Completable exchangeDeclare(String exchange, String type, boolean durable, boolean autoDelete, JsonObject config)
exchange
- type
- durable
- autoDelete
- config
- public Completable rxExchangeDeclare(String exchange, String type, boolean durable, boolean autoDelete, JsonObject config)
exchange
- type
- durable
- autoDelete
- config
- public Completable exchangeDelete(String exchange)
exchange
- public Completable rxExchangeDelete(String exchange)
exchange
- public Completable exchangeBind(String destination, String source, String routingKey)
destination
- source
- routingKey
- public Completable rxExchangeBind(String destination, String source, String routingKey)
destination
- source
- routingKey
- public Completable exchangeBind(String destination, String source, String routingKey, Map<String,Object> arguments)
destination
- source
- routingKey
- arguments
- public Completable rxExchangeBind(String destination, String source, String routingKey, Map<String,Object> arguments)
destination
- source
- routingKey
- arguments
- public Completable exchangeUnbind(String destination, String source, String routingKey)
destination
- source
- routingKey
- public Completable rxExchangeUnbind(String destination, String source, String routingKey)
destination
- source
- routingKey
- public Completable exchangeUnbind(String destination, String source, String routingKey, Map<String,Object> arguments)
destination
- source
- routingKey
- arguments
- public Completable rxExchangeUnbind(String destination, String source, String routingKey, Map<String,Object> arguments)
destination
- source
- routingKey
- arguments
- public Single<JsonObject> queueDeclareAuto()
public Single<JsonObject> rxQueueDeclareAuto()
public Completable queueBind(String queue, String exchange, String routingKey)
queue
- exchange
- routingKey
- public Completable rxQueueBind(String queue, String exchange, String routingKey)
queue
- exchange
- routingKey
- public Completable queueBind(String queue, String exchange, String routingKey, Map<String,Object> arguments)
queue
- exchange
- routingKey
- arguments
- public Completable rxQueueBind(String queue, String exchange, String routingKey, Map<String,Object> arguments)
queue
- exchange
- routingKey
- arguments
- public Completable queueUnbind(String queue, String exchange, String routingKey)
queue
- exchange
- routingKey
- public Completable rxQueueUnbind(String queue, String exchange, String routingKey)
queue
- exchange
- routingKey
- public Completable queueUnbind(String queue, String exchange, String routingKey, Map<String,Object> arguments)
queue
- exchange
- routingKey
- arguments
- public Completable rxQueueUnbind(String queue, String exchange, String routingKey, Map<String,Object> arguments)
queue
- exchange
- routingKey
- arguments
- public Single<Long> messageCount(String queue)
queue
- public Single<Long> rxMessageCount(String queue)
queue
- public Completable start()
public Completable rxStart()
public Completable stop()
public Completable rxStop()
public boolean isConnected()
public Completable restartConnect(int attempts)
attempts
- number of attemptspublic Completable rxRestartConnect(int attempts)
attempts
- number of attemptspublic boolean isOpenChannel()
public Completable basicPublish(String exchange, String routingKey, com.rabbitmq.client.BasicProperties properties, Buffer body)
exchange
- routingKey
- properties
- body
- public Completable rxBasicPublish(String exchange, String routingKey, com.rabbitmq.client.BasicProperties properties, Buffer body)
exchange
- routingKey
- properties
- body
- public Completable 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 Completable 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 Single<com.rabbitmq.client.AMQP.Queue.DeclareOk> 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 Single<com.rabbitmq.client.AMQP.Queue.DeclareOk> 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 Single<com.rabbitmq.client.AMQP.Queue.DeleteOk> queueDelete(String queue)
queue
- public Single<com.rabbitmq.client.AMQP.Queue.DeleteOk> rxQueueDelete(String queue)
queue
- public Single<com.rabbitmq.client.AMQP.Queue.DeleteOk> 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.