package io.vertx.rabbitmq;

import com.rabbitmq.client.AMQP;
import com.rabbitmq.client.BasicProperties;
import com.rabbitmq.client.Channel;
import com.rabbitmq.client.ConfirmListener;
import com.rabbitmq.client.Consumer;
import io.vertx.codegen.annotations.GenIgnore;
import io.vertx.codegen.annotations.Nullable;
import io.vertx.codegen.annotations.VertxGen;
import io.vertx.core.AsyncResult;
import io.vertx.core.Future;
import io.vertx.core.Handler;
import io.vertx.core.Promise;
import io.vertx.core.Vertx;
import io.vertx.core.buffer.Buffer;
import io.vertx.core.json.JsonObject;
import io.vertx.core.streams.ReadStream;
import io.vertx.rabbitmq.impl.RabbitMQClientImpl;
import java.util.Map;

Author:Nick Scavelli
/** * @author <a href="mailto:nscavell@redhat.com">Nick Scavelli</a> */
@VertxGen public interface RabbitMQClient {
Create and return a client configured with the default options.
Params:
  • vertx – the vertx instance
Returns:the client
/** * Create and return a client configured with the default options. * * @param vertx the vertx instance * @return the client */
static RabbitMQClient create(Vertx vertx) { return new RabbitMQClientImpl(vertx, new RabbitMQOptions()); }
Create and return a client.
Params:
  • vertx – the vertx instance
  • config – the client config
Returns:the client
/** * Create and return a client. * * @param vertx the vertx instance * @param config the client config * @return the client */
static RabbitMQClient create(Vertx vertx, RabbitMQOptions config) { return new RabbitMQClientImpl(vertx, config); }
Set a callback to be called whenever a new connection is established. This callback must be idempotent - it will be called each time a connection is established, which may be multiple times against the same instance. Callbacks will be added to a list and called in the order they were added, the only way to remove callbacks is to create a new client. These callbacks should be used to establish any Rabbit MQ server objects that are required - exchanges, queues, bindings, etc. Each callback will receive a Promise that it must complete in order to pass control to the next callback (or back to the RabbitMQClient). If the callback fails the promise the RabbitMQClient will be unable to make a connection (it will attempt to connect again according to its retry configuration). If the promise is not completed or failed by a callback the RabbitMQClient will not start (it will hang indefinitely). Other methods on the client may be used in the callback - it is specifically expected that RabbitMQ objects will be declared, but the publish and consume methods must not be used. The connection established callbacks are particularly important with the RabbitMQPublisher and RabbitMQConsumer when they are used with servers that may failover to another instance of the server that does not have the same exchanges/queues configured on it. In this situation these callbacks are the only opportunity to create exchanges, queues and bindings before the client will attempt to use them when it re-establishes connection. If your failover cluster is guaranteed to have the appropriate objects already configured then it is not necessary to use the callbacks.
Params:
  • connectionEstablishedCallback – callback to be called whenever a new connection is established.
/** * Set a callback to be called whenever a new connection is established. * This callback must be idempotent - it will be called each time a connection is established, which may be multiple times against the same instance. * Callbacks will be added to a list and called in the order they were added, the only way to remove callbacks is to create a new client. * * These callbacks should be used to establish any Rabbit MQ server objects that are required - exchanges, queues, bindings, etc. * Each callback will receive a Promise<Void> that it must complete in order to pass control to the next callback (or back to the RabbitMQClient). * If the callback fails the promise the RabbitMQClient will be unable to make a connection (it will attempt to connect again according to its retry configuration). * If the promise is not completed or failed by a callback the RabbitMQClient will not start (it will hang indefinitely). * * Other methods on the client may be used in the callback - * it is specifically expected that RabbitMQ objects will be declared, but the publish and consume methods must not be used. * * The connection established callbacks are particularly important with the RabbitMQPublisher and RabbitMQConsumer when they are used with * servers that may failover to another instance of the server that does not have the same exchanges/queues configured on it. * In this situation these callbacks are the only opportunity to create exchanges, queues and bindings before the client will attempt to use them when it * re-establishes connection. * If your failover cluster is guaranteed to have the appropriate objects already configured then it is not necessary to use the callbacks. * * @param connectionEstablishedCallback callback to be called whenever a new connection is established. */
@GenIgnore void addConnectionEstablishedCallback(Handler<Promise<Void>> connectionEstablishedCallback);
Like create(Vertx, RabbitMQOptions) but with a JsonObject config object.
/** * Like {@link #create(Vertx, RabbitMQOptions)} but with a {@link JsonObject} config object. */
@GenIgnore static RabbitMQClient create(Vertx vertx, JsonObject config) { return new RabbitMQClientImpl(vertx, new RabbitMQOptions(config)); } //TODO: Think about splitting this out into different API's with specific roles (admin, pub, sub) //TODO: Simplify/Change name of API methods to match more vert.x type verbiage ?
Acknowledge one or several received messages. Supply the deliveryTag from the AMQP.Basic.GetOk or AMQP.Basic.Deliver method containing the received message being acknowledged.
See Also:
  • basicAck.basicAck(long, boolean)
/** * Acknowledge one or several received messages. Supply the deliveryTag from the AMQP.Basic.GetOk or AMQP.Basic.Deliver * method containing the received message being acknowledged. * * @see com.rabbitmq.client.Channel#basicAck(long, boolean) */
void basicAck(long deliveryTag, boolean multiple, Handler<AsyncResult<Void>> resultHandler);
Like basicAck(long, boolean, Handler<AsyncResult<Void>>) but returns a Future of the asynchronous result
/** * Like {@link #basicAck(long, boolean, Handler)} but returns a {@code Future} of the asynchronous result */
Future<Void> basicAck(long deliveryTag, boolean multiple);
Reject one or several received messages.
See Also:
  • basicNack.basicNack(long, boolean, boolean)
/** * Reject one or several received messages. * * @see com.rabbitmq.client.Channel#basicNack(long, boolean, boolean) */
void basicNack(long deliveryTag, boolean multiple, boolean requeue, Handler<AsyncResult<Void>> resultHandler);
Like basicNack(long, boolean, boolean, Handler<AsyncResult<Void>>) but returns a Future of the asynchronous result
/** * Like {@link #basicNack(long, boolean, boolean, Handler)} but returns a {@code Future} of the asynchronous result */
Future<Void> basicNack(long deliveryTag, boolean multiple, boolean requeue);
Retrieve a message from a queue using AMQP.Basic.Get
See Also:
  • basicGet.basicGet(String, boolean)
/** * Retrieve a message from a queue using AMQP.Basic.Get * * @see com.rabbitmq.client.Channel#basicGet(String, boolean) */
void basicGet(String queue, boolean autoAck, Handler<AsyncResult<RabbitMQMessage>> resultHandler);
Like basicGet(String, boolean, Handler<AsyncResult<RabbitMQMessage>>) but returns a Future of the asynchronous result
/** * Like {@link #basicGet(String, boolean, Handler)} but returns a {@code Future} of the asynchronous result */
Future<RabbitMQMessage> basicGet(String queue, boolean autoAck);
See Also:
/** * @see com.rabbitmq.client.Channel#basicConsume(String, Consumer) * @see RabbitMQClient#basicConsumer(String, Handler) */
default void basicConsumer(String queue, Handler<AsyncResult<RabbitMQConsumer>> resultHandler) { basicConsumer(queue, new QueueOptions(), resultHandler); }
Like basicConsumer(String, Handler<AsyncResult<RabbitMQConsumer>>) but returns a Future of the asynchronous result
/** * Like {@link #basicConsumer(String, Handler)} but returns a {@code Future} of the asynchronous result */
default Future<RabbitMQConsumer> basicConsumer(String queue) { return basicConsumer(queue, new QueueOptions()); }
Create a consumer with the given options.
Params:
  • queue – the name of a queue
  • options – options for queue
  • resultHandler – 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
See Also:
/** * Create a consumer with the given {@code options}. * * @param queue the name of a queue * @param options options for queue * @param resultHandler 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 {@link RabbitMQConsumer} * @see com.rabbitmq.client.Channel#basicConsume(String, boolean, String, Consumer) */
void basicConsumer(String queue, QueueOptions options, Handler<AsyncResult<RabbitMQConsumer>> resultHandler);
Like basicConsumer(String, QueueOptions, Handler<AsyncResult<RabbitMQConsumer>>) but returns a Future of the asynchronous result
/** * Like {@link #basicConsumer(String, QueueOptions, Handler)} but returns a {@code Future} of the asynchronous result */
Future<RabbitMQConsumer> basicConsumer(String queue, QueueOptions options);
Publish a message. Publishing to a non-existent exchange will result in a channel-level protocol exception, which closes the channel. Invocations of Channel#basicPublish will eventually block if a resource-driven alarm is in effect.
See Also:
  • basicPublish.basicPublish(String, String, BasicProperties, byte[])
/** * Publish a message. Publishing to a non-existent exchange will result in a channel-level protocol exception, * which closes the channel. Invocations of Channel#basicPublish will eventually block if a resource-driven alarm is in effect. * * @see com.rabbitmq.client.Channel#basicPublish(String, String, AMQP.BasicProperties, byte[]) */
void basicPublish(String exchange, String routingKey, Buffer body, Handler<AsyncResult<Void>> resultHandler);
Like basicPublish(String, String, Buffer, Handler<AsyncResult<Void>>) but returns a Future of the asynchronous result
/** * Like {@link #basicPublish(String, String, Buffer, Handler)} but returns a {@code Future} of the asynchronous result */
Future<Void> basicPublish(String exchange, String routingKey, Buffer body);
Publish a message. Publishing to a non-existent exchange will result in a channel-level protocol exception, which closes the channel. Invocations of Channel#basicPublish will eventually block if a resource-driven alarm is in effect.
See Also:
  • basicPublish.basicPublish(String, String, BasicProperties, byte[])
/** * Publish a message. Publishing to a non-existent exchange will result in a channel-level protocol exception, * which closes the channel. Invocations of Channel#basicPublish will eventually block if a resource-driven alarm is in effect. * * @see com.rabbitmq.client.Channel#basicPublish(String, String, AMQP.BasicProperties, byte[]) */
@GenIgnore(GenIgnore.PERMITTED_TYPE) void basicPublish(String exchange, String routingKey, BasicProperties properties, Buffer body, Handler<AsyncResult<Void>> resultHandler);
Like basicPublish(String, String, BasicProperties, Buffer, Handler<AsyncResult<Void>>) but returns a Future of the asynchronous result
/** * Like {@link #basicPublish(String, String, BasicProperties, Buffer, Handler)} but returns a {@code Future} of the asynchronous result */
@GenIgnore(GenIgnore.PERMITTED_TYPE) Future<Void> basicPublish(String exchange, String routingKey, BasicProperties properties, Buffer body);
Publish a message. Publishing to a non-existent exchange will result in a channel-level protocol exception, which closes the channel. Invocations of Channel#basicPublish will eventually block if a resource-driven alarm is in effect. The deliveryTagHandler will be called before the message is sent, which is necessary because the confirmation may arrive asynchronously before the resultHandler is called.
Params:
  • 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.
See Also:
/** * Publish a message. Publishing to a non-existent exchange will result in a channel-level protocol exception, * which closes the channel. Invocations of Channel#basicPublish will eventually block if a resource-driven alarm is in effect. * * The deliveryTagHandler will be called before the message is sent, which is necessary because the confirmation may arrive * asynchronously before the resultHandler is called. * * @param 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. * @see com.rabbitmq.client.Channel#basicPublish(String, String, AMQP.BasicProperties, byte[]) */
@GenIgnore(GenIgnore.PERMITTED_TYPE) void basicPublishWithDeliveryTag(String exchange, String routingKey, BasicProperties properties, Buffer body, @Nullable Handler<Long> deliveryTagHandler, Handler<AsyncResult<Void>> resultHandler);
Publish a message. Publishing to a non-existent exchange will result in a channel-level protocol exception, which closes the channel. Invocations of Channel#basicPublish will eventually block if a resource-driven alarm is in effect.
Params:
  • deliveryTagHandler – callback to capture the deliveryTag for this message. Note that this will be called synchronously in the context of the client.
See Also:
/** * Publish a message. Publishing to a non-existent exchange will result in a channel-level protocol exception, * which closes the channel. Invocations of Channel#basicPublish will eventually block if a resource-driven alarm is in effect. * * @param deliveryTagHandler callback to capture the deliveryTag for this message. Note that this will be called synchronously in the context of the client. * @see com.rabbitmq.client.Channel#basicPublish(String, String, AMQP.BasicProperties, byte[]) */
@GenIgnore(GenIgnore.PERMITTED_TYPE) Future<Void> basicPublishWithDeliveryTag(String exchange, String routingKey, BasicProperties properties, Buffer body, @Nullable Handler<Long> deliveryTagHandler);
Add a Confirm Listener to the channel. Note that this will automatically call confirmSelect, it is not necessary to call that too.
Params:
  • maxQueueSize – maximum size of the queue of confirmations
  • resultHandler – a handler through which you can find out the operation status; if the operation succeeds you can begin to receive confirmations through an instance of RabbitMQConfirmListener
See Also:
/** * Add a Confirm Listener to the channel. * Note that this will automatically call confirmSelect, it is not necessary to call that too. * * @param maxQueueSize maximum size of the queue of confirmations * @param resultHandler a handler through which you can find out the operation status; * if the operation succeeds you can begin to receive confirmations * through an instance of {@link RabbitMQConfirmListener} * @see com.rabbitmq.client.Channel#addConfirmListener(ConfirmListener) */
void addConfirmListener(int maxQueueSize, Handler<AsyncResult<ReadStream<RabbitMQConfirmation>>> resultHandler);
Add a Confirm Listener to the channel. Like addConfirmListener(int) but returns a Future of the asynchronous result Note that this will automatically call confirmSelect, it is not necessary to call that too.
Params:
  • maxQueueSize – maximum size of the queue of confirmations
See Also:
Returns:a future through which you can find out the operation status; if the operation succeeds you can begin to receive confirmations through an instance of RabbitMQConfirmListener
/** * Add a Confirm Listener to the channel. * Like {@link #addConfirmListener(Handler)} but returns a {@code Future} of the asynchronous result * Note that this will automatically call confirmSelect, it is not necessary to call that too. * * @param maxQueueSize maximum size of the queue of confirmations * @return a future through which you can find out the operation status; * if the operation succeeds you can begin to receive confirmations * through an instance of {@link RabbitMQConfirmListener} * @see com.rabbitmq.client.Channel#addConfirmListener(ConfirmListener) */
Future<ReadStream<RabbitMQConfirmation>> addConfirmListener(int maxQueueSize);
Enables publisher acknowledgements on this channel. Can be called once during client initialisation. Calls to basicPublish() will have to be confirmed.
See Also:
  • confirmSelect.confirmSelect()
@linkhttp://www.rabbitmq.com/confirms.html
/** * Enables publisher acknowledgements on this channel. Can be called once during client initialisation. Calls to basicPublish() * will have to be confirmed. * * @see Channel#confirmSelect() * @link http://www.rabbitmq.com/confirms.html */
void confirmSelect(Handler<AsyncResult<Void>> resultHandler);
Like confirmSelect(Handler<AsyncResult<Void>>) but returns a Future of the asynchronous result
/** * Like {@link #confirmSelect(Handler)} but returns a {@code Future} of the asynchronous result */
Future<Void> confirmSelect();
Wait until all messages published since the last call have been either ack'd or nack'd by the broker. This will incur slight performance loss at the expense of higher write consistency. If desired, multiple calls to basicPublish() can be batched before confirming.
Throws:
  • IOException – Throws an IOException if the message was not written to the queue.
See Also:
  • waitForConfirms.waitForConfirms()
@linkhttp://www.rabbitmq.com/confirms.html
/** * Wait until all messages published since the last call have been either ack'd or nack'd by the broker. * This will incur slight performance loss at the expense of higher write consistency. * If desired, multiple calls to basicPublish() can be batched before confirming. * * @see Channel#waitForConfirms() * @link http://www.rabbitmq.com/confirms.html * * @throws java.io.IOException Throws an IOException if the message was not written to the queue. */
void waitForConfirms(Handler<AsyncResult<Void>> resultHandler);
Like waitForConfirms(Handler<AsyncResult<Void>>) but returns a Future of the asynchronous result
/** * Like {@link #waitForConfirms(Handler)} but returns a {@code Future} of the asynchronous result */
Future<Void> waitForConfirms();
Wait until all messages published since the last call have been either ack'd or nack'd by the broker; or until timeout elapses. If the timeout expires a TimeoutException is thrown.
Params:
  • timeout –
Throws:
  • IOException – Throws an IOException if the message was not written to the queue.
See Also:
@linkhttp://www.rabbitmq.com/confirms.html
/** * Wait until all messages published since the last call have been either ack'd or nack'd by the broker; or until timeout elapses. If the timeout expires a TimeoutException is thrown. * * @param timeout * * @see io.vertx.rabbitmq.impl.RabbitMQClientImpl#waitForConfirms(Handler) * @link http://www.rabbitmq.com/confirms.html * * @throws java.io.IOException Throws an IOException if the message was not written to the queue. */
void waitForConfirms(long timeout, Handler<AsyncResult<Void>> resultHandler);
Like waitForConfirms(long, Handler<AsyncResult<Void>>) but returns a Future of the asynchronous result
/** * Like {@link #waitForConfirms(long, Handler)} but returns a {@code Future} of the asynchronous result */
Future<Void> waitForConfirms(long timeout);
Request a specific prefetchCount "quality of service" settings for this channel.
Params:
  • prefetchCount – maximum number of messages that the server will deliver, 0 if unlimited
  • resultHandler – handler called when operation is done with a result of the operation
See Also:
  • basicQos(int, int, boolean, Handler)
/** * Request a specific prefetchCount "quality of service" settings * for this channel. * * @see #basicQos(int, int, boolean, Handler) * @param prefetchCount maximum number of messages that the server * will deliver, 0 if unlimited * @param resultHandler handler called when operation is done with a result of the operation */
default void basicQos(int prefetchCount, Handler<AsyncResult<Void>> resultHandler) { basicQos(prefetchCount, false, resultHandler); }
Like basicQos(int, Handler<AsyncResult<Void>>) but returns a Future of the asynchronous result
/** * Like {@link #basicQos(int, Handler)} but returns a {@code Future} of the asynchronous result */
default Future<Void> basicQos(int prefetchCount) { return basicQos(prefetchCount, false); }
Request a specific prefetchCount "quality of service" settings for this channel.
Params:
  • prefetchCount – maximum number of messages that the server will deliver, 0 if unlimited
  • global – true if the settings should be applied to the entire channel rather than each consumer
  • resultHandler – handler called when operation is done with a result of the operation
See Also:
  • basicQos(int, int, boolean, Handler)
/** * Request a specific prefetchCount "quality of service" settings * for this channel. * * @see #basicQos(int, int, boolean, Handler) * @param prefetchCount maximum number of messages that the server * will deliver, 0 if unlimited * @param global true if the settings should be applied to the * entire channel rather than each consumer * @param resultHandler handler called when operation is done with a result of the operation */
default void basicQos(int prefetchCount, boolean global, Handler<AsyncResult<Void>> resultHandler) { basicQos(0, prefetchCount, global, resultHandler); }
Like basicQos(int, boolean, Handler<AsyncResult<Void>>) but returns a Future of the asynchronous result
/** * Like {@link #basicQos(int, boolean, Handler)} but returns a {@code Future} of the asynchronous result */
default Future<Void> basicQos(int prefetchCount, boolean global) { return basicQos(0, prefetchCount, global); }
Request specific "quality of service" settings. These settings impose limits on the amount of data the server will deliver to consumers before requiring acknowledgements. Thus they provide a means of consumer-initiated flow control.
Params:
  • prefetchSize – maximum amount of content (measured in octets) that the server will deliver, 0 if unlimited
  • prefetchCount – maximum number of messages that the server will deliver, 0 if unlimited
  • global – true if the settings should be applied to the entire channel rather than each consumer
  • resultHandler – handler called when operation is done with a result of the operation
See Also:
  • Qos
/** * Request specific "quality of service" settings. * * These settings impose limits on the amount of data the server * will deliver to consumers before requiring acknowledgements. * Thus they provide a means of consumer-initiated flow control. * @see com.rabbitmq.client.AMQP.Basic.Qos * @param prefetchSize maximum amount of content (measured in * octets) that the server will deliver, 0 if unlimited * @param prefetchCount maximum number of messages that the server * will deliver, 0 if unlimited * @param global true if the settings should be applied to the * entire channel rather than each consumer * @param resultHandler handler called when operation is done with a result of the operation */
void basicQos(int prefetchSize, int prefetchCount, boolean global, Handler<AsyncResult<Void>> resultHandler);
Like basicQos(int, int, boolean, Handler<AsyncResult<Void>>) but returns a Future of the asynchronous result
/** * Like {@link #basicQos(int, int, boolean, Handler)} but returns a {@code Future} of the asynchronous result */
Future<Void> basicQos(int prefetchSize, int prefetchCount, boolean global);
Declare an exchange.
See Also:
  • exchangeDeclare.exchangeDeclare(String, String, boolean, boolean, Map)
/** * Declare an exchange. * * @see com.rabbitmq.client.Channel#exchangeDeclare(String, String, boolean, boolean, Map) */
void exchangeDeclare(String exchange, String type, boolean durable, boolean autoDelete, Handler<AsyncResult<Void>> resultHandler);
Like exchangeDeclare(String, String, boolean, boolean, Handler<AsyncResult<Void>>) but returns a Future of the asynchronous result
/** * Like {@link #exchangeDeclare(String, String, boolean, boolean, Handler)} but returns a {@code Future} of the asynchronous result */
Future<Void> exchangeDeclare(String exchange, String type, boolean durable, boolean autoDelete);
Declare an exchange with additional parameters such as dead lettering, an alternate exchange or TTL.
See Also:
  • exchangeDeclare.exchangeDeclare(String, String, boolean, boolean, Map)
/** * Declare an exchange with additional parameters such as dead lettering, an alternate exchange or TTL. * * @see com.rabbitmq.client.Channel#exchangeDeclare(String, String, boolean, boolean, Map) */
void exchangeDeclare(String exchange, String type, boolean durable, boolean autoDelete, JsonObject config, Handler<AsyncResult<Void>> resultHandler); /** * Like {@link #exchangeDeclare(String, String, boolean, boolean, JsonObject, Handler)} but returns a {@code Future} of the asynchronous result */ Future<Void> exchangeDeclare(String exchange, String type, boolean durable, boolean autoDelete, JsonObject config);
Delete an exchange, without regard for whether it is in use or not.
See Also:
  • exchangeDelete.exchangeDelete(String)
/** * Delete an exchange, without regard for whether it is in use or not. * * @see com.rabbitmq.client.Channel#exchangeDelete(String) */
void exchangeDelete(String exchange, Handler<AsyncResult<Void>> resultHandler);
Like exchangeDelete(String, Handler<AsyncResult<Void>>) but returns a Future of the asynchronous result
/** * Like {@link #exchangeDelete(String, Handler)} but returns a {@code Future} of the asynchronous result */
Future<Void> exchangeDelete(String exchange);
Bind an exchange to an exchange.
See Also:
  • exchangeBind.exchangeBind(String, String, String)
/** * Bind an exchange to an exchange. * * @see com.rabbitmq.client.Channel#exchangeBind(String, String, String) */
void exchangeBind(String destination, String source, String routingKey, Handler<AsyncResult<Void>> resultHandler);
Like exchangeBind(String, String, String, Handler<AsyncResult<Void>>) but returns a Future of the asynchronous result
/** * Like {@link #exchangeBind(String, String, String, Handler)} but returns a {@code Future} of the asynchronous result */
Future<Void> exchangeBind(String destination, String source, String routingKey);
Bind an exchange to an exchange.
See Also:
  • com.rabbitmq.client.Channel#exchangeBind(String, String, String, Map)
/** * Bind an exchange to an exchange. * * @see com.rabbitmq.client.Channel#exchangeBind(String, String, String, Map<String, Object>) */
void exchangeBind(String destination, String source, String routingKey, Map<String, Object> arguments, Handler<AsyncResult<Void>> resultHandler); /** * Like {@link #exchangeBind(String, String, String, Map, Handler)} but returns a {@code Future} of the asynchronous result */ Future<Void> exchangeBind(String destination, String source, String routingKey, Map<String, Object> arguments);
Unbind an exchange from an exchange.
See Also:
  • exchangeUnbind.exchangeUnbind(String, String, String)
/** * Unbind an exchange from an exchange. * * @see com.rabbitmq.client.Channel#exchangeUnbind(String, String, String) */
void exchangeUnbind(String destination, String source, String routingKey, Handler<AsyncResult<Void>> resultHandler);
Like exchangeUnbind(String, String, String, Handler<AsyncResult<Void>>) but returns a Future of the asynchronous result
/** * Like {@link #exchangeUnbind(String, String, String, Handler)} but returns a {@code Future} of the asynchronous result */
Future<Void> exchangeUnbind(String destination, String source, String routingKey);
Unbind an exchange from an exchange.
See Also:
  • com.rabbitmq.client.Channel#exchangeUnbind(String, String, String, Map)
/** * Unbind an exchange from an exchange. * * @see com.rabbitmq.client.Channel#exchangeUnbind(String, String, String, Map<String, Object>) */
void exchangeUnbind(String destination, String source, String routingKey, Map<String, Object> arguments, Handler<AsyncResult<Void>> resultHandler); /** * Like {@link #exchangeUnbind(String, String, String, Map, Handler)} but returns a {@code Future} of the asynchronous result */ Future<Void> exchangeUnbind(String destination, String source, String routingKey, Map<String, Object> arguments);
Actively declare a server-named exclusive, autodelete, non-durable queue.
See Also:
  • queueDeclare.queueDeclare()
/** * Actively declare a server-named exclusive, autodelete, non-durable queue. * * @see com.rabbitmq.client.Channel#queueDeclare() */
//TODO: Auto ? void queueDeclareAuto(Handler<AsyncResult<JsonObject>> resultHandler);
Like queueDeclareAuto(Handler<AsyncResult<JsonObject>>) but returns a Future of the asynchronous result
/** * Like {@link #queueDeclareAuto(Handler)} but returns a {@code Future} of the asynchronous result */
Future<JsonObject> queueDeclareAuto();
Declare a queue
See Also:
  • queueDeclare.queueDeclare(String, boolean, boolean, boolean, Map)
/** * Declare a queue * * @see com.rabbitmq.client.Channel#queueDeclare(String, boolean, boolean, boolean, java.util.Map) */
@GenIgnore(GenIgnore.PERMITTED_TYPE) void queueDeclare(String queue, boolean durable, boolean exclusive, boolean autoDelete, Handler<AsyncResult<AMQP.Queue.DeclareOk>> resultHandler);
Like queueDeclare(String, boolean, boolean, boolean, Handler<AsyncResult<DeclareOk>>) but returns a Future of the asynchronous result
/** * Like {@link #queueDeclare(String, boolean, boolean, boolean, Handler)} but returns a {@code Future} of the asynchronous result */
@GenIgnore(GenIgnore.PERMITTED_TYPE) Future<AMQP.Queue.DeclareOk> queueDeclare(String queue, boolean durable, boolean exclusive, boolean autoDelete);
Declare a queue with config options
See Also:
  • queueDeclare.queueDeclare(String, boolean, boolean, boolean, Map)
/** * Declare a queue with config options * * @see com.rabbitmq.client.Channel#queueDeclare(String, boolean, boolean, boolean, java.util.Map) */
@GenIgnore(GenIgnore.PERMITTED_TYPE) void queueDeclare(String queue, boolean durable, boolean exclusive, boolean autoDelete, JsonObject config, Handler<AsyncResult<AMQP.Queue.DeclareOk>> resultHandler); /** * Like {@link #queueDeclare(String, boolean, boolean, boolean, JsonObject, Handler)} but returns a {@code Future} of the asynchronous result */ @GenIgnore(GenIgnore.PERMITTED_TYPE) Future<AMQP.Queue.DeclareOk> queueDeclare(String queue, boolean durable, boolean exclusive, boolean autoDelete, JsonObject config);
Delete a queue, without regard for whether it is in use or has messages on it
See Also:
  • queueDelete.queueDelete(String)
/** * Delete a queue, without regard for whether it is in use or has messages on it * * @see com.rabbitmq.client.Channel#queueDelete(String) */
@GenIgnore(GenIgnore.PERMITTED_TYPE) void queueDelete(String queue, Handler<AsyncResult<AMQP.Queue.DeleteOk>> resultHandler);
Like queueDelete(String, Handler<AsyncResult<DeleteOk>>) but returns a Future of the asynchronous result
/** * Like {@link #queueDelete(String, Handler)} but returns a {@code Future} of the asynchronous result */
@GenIgnore(GenIgnore.PERMITTED_TYPE) Future<AMQP.Queue.DeleteOk> queueDelete(String queue);
Delete a queue
See Also:
  • queueDelete.queueDelete(String, boolean, boolean)
/** * Delete a queue * * @see com.rabbitmq.client.Channel#queueDelete(String, boolean, boolean) */
@GenIgnore(GenIgnore.PERMITTED_TYPE) void queueDeleteIf(String queue, boolean ifUnused, boolean ifEmpty, Handler<AsyncResult<AMQP.Queue.DeleteOk>> resultHandler);
Like queueDeleteIf(String, boolean, boolean, Handler<AsyncResult<DeleteOk>>) but returns a Future of the asynchronous result
/** * Like {@link #queueDeleteIf(String, boolean, boolean, Handler)} but returns a {@code Future} of the asynchronous result */
@GenIgnore(GenIgnore.PERMITTED_TYPE) Future<AMQP.Queue.DeleteOk> queueDeleteIf(String queue, boolean ifUnused, boolean ifEmpty);
Bind a queue to an exchange
See Also:
  • queueBind.queueBind(String, String, String)
/** * Bind a queue to an exchange * * @see com.rabbitmq.client.Channel#queueBind(String, String, String) */
void queueBind(String queue, String exchange, String routingKey, Handler<AsyncResult<Void>> resultHandler);
Like queueBind(String, String, String, Handler<AsyncResult<Void>>) but returns a Future of the asynchronous result
/** * Like {@link #queueBind(String, String, String, Handler)} but returns a {@code Future} of the asynchronous result */
Future<Void> queueBind(String queue, String exchange, String routingKey);
Bind a queue to an exchange
See Also:
  • com.rabbitmq.client.Channel#queueBind(String, String, String, Map)
/** * Bind a queue to an exchange * * @see com.rabbitmq.client.Channel#queueBind(String, String, String, Map<String, Object>) */
void queueBind(String queue, String exchange, String routingKey, Map<String, Object> arguments, Handler<AsyncResult<Void>> resultHandler);
Like queueBind(String, String, String, Map<String,Object>, Handler<AsyncResult<Void>>) but returns a Future of the asynchronous result
/** * Like {@link #queueBind(String, String, String, Map, Handler)} but returns a {@code Future} of the asynchronous result */
Future<Void> queueBind(String queue, String exchange, String routingKey, Map<String, Object> arguments);
Unbind a queue from an exchange
See Also:
  • queueUnbind.queueUnbind(String, String, String)
/** * Unbind a queue from an exchange * * @see com.rabbitmq.client.Channel#queueUnbind(String, String, String) */
void queueUnbind(String queue, String exchange, String routingKey, Handler<AsyncResult<Void>> resultHandler);
Like queueUnbind(String, String, String, Handler<AsyncResult<Void>>) but returns a Future of the asynchronous result
/** * Like {@link #queueUnbind(String, String, String, Handler)} but returns a {@code Future} of the asynchronous result */
Future<Void> queueUnbind(String queue, String exchange, String routingKey);
Unbind a queue from an exchange
See Also:
  • com.rabbitmq.client.Channel#queueUnbind(String, String, String, Map)
/** * Unbind a queue from an exchange * * @see com.rabbitmq.client.Channel#queueUnbind(String, String, String, Map<String, Object>) */
void queueUnbind(String queue, String exchange, String routingKey, Map<String, Object> arguments, Handler<AsyncResult<Void>> resultHandler); /** * Like {@link #queueUnbind(String, String, String, Map, Handler)} but returns a {@code Future} of the asynchronous result */ Future<Void> queueUnbind(String queue, String exchange, String routingKey, Map<String, Object> arguments);
Returns the number of messages in a queue ready to be delivered.
See Also:
  • messageCount.messageCount(String)
/** * Returns the number of messages in a queue ready to be delivered. * * @see com.rabbitmq.client.Channel#messageCount(String) */
void messageCount(String queue, Handler<AsyncResult<Long>> resultHandler);
Like messageCount(String, Handler<AsyncResult<Long>>) but returns a Future of the asynchronous result
/** * Like {@link #messageCount(String, Handler)} but returns a {@code Future} of the asynchronous result */
Future<Long> messageCount(String queue);
Start the rabbitMQ client. Create the connection and the channel.
See Also:
  • createChannel.createChannel()
/** * Start the rabbitMQ client. Create the connection and the channel. * * @see com.rabbitmq.client.Connection#createChannel() */
void start(Handler<AsyncResult<Void>> resultHandler);
Like start(Handler<AsyncResult<Void>>) but returns a Future of the asynchronous result
/** * Like {@link #start(Handler)} but returns a {@code Future} of the asynchronous result */
Future<Void> start();
Stop the rabbitMQ client. Close the connection and its channel.
See Also:
  • close.close()
/** * Stop the rabbitMQ client. Close the connection and its channel. * * @see com.rabbitmq.client.Connection#close() */
void stop(Handler<AsyncResult<Void>> resultHandler);
Like stop(Handler<AsyncResult<Void>>) but returns a Future of the asynchronous result
/** * Like {@link #stop(Handler)} but returns a {@code Future} of the asynchronous result */
Future<Void> stop();
Check if a connection is open
See Also:
Returns:true when the connection is open, false otherwise
/** * Check if a connection is open * * @return true when the connection is open, false otherwise * @see com.rabbitmq.client.ShutdownNotifier#isOpen() */
boolean isConnected();
Check if a channel is open
See Also:
Returns:true when the connection is open, false otherwise
/** * Check if a channel is open * * @return true when the connection is open, false otherwise * @see com.rabbitmq.client.ShutdownNotifier#isOpen() */
boolean isOpenChannel(); }