Packages

c

vertices.rabbitmq

VertxRabbitMQClientOps

implicit final class VertxRabbitMQClientOps extends AnyVal

Linear Supertypes
AnyVal, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. VertxRabbitMQClientOps
  2. AnyVal
  3. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. Protected

Instance Constructors

  1. new VertxRabbitMQClientOps(target: RabbitMQClient)

Value Members

  1. final def !=(arg0: Any): Boolean
    Definition Classes
    Any
  2. final def ##(): Int
    Definition Classes
    Any
  3. final def ==(arg0: Any): Boolean
    Definition Classes
    Any
  4. final def asInstanceOf[T0]: T0
    Definition Classes
    Any
  5. def basicAckL(deliveryTag: Long, multiple: Boolean): Task[JsonObject]

    Acknowledge one or several received messages.

    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

    com.rabbitmq.client.Channel#basicAck(long, boolean)

  6. def basicConsumerL(queue: String, options: QueueOptions): Task[RabbitMQConsumer]

    Create a consumer with the given options.

    Create a consumer with the given options.

    queue

    the name of a queue

    options

    options for queue

    See also

    com.rabbitmq.client.Channel#basicConsume(String, boolean, String, Consumer)

  7. def basicConsumerL(queue: String): Task[RabbitMQConsumer]

    See also

    com.rabbitmq.client.Channel#basicConsume(String, Consumer)

    RabbitMQClient#basicConsumer(String, Handler)

  8. def basicGetL(queue: String, autoAck: Boolean): Task[JsonObject]

    Retrieve a message from a queue using AMQP.Basic.Get

    Retrieve a message from a queue using AMQP.Basic.Get

    See also

    com.rabbitmq.client.Channel#basicGet(String, boolean)

  9. def basicNackL(deliveryTag: Long, multiple: Boolean, requeue: Boolean): Task[JsonObject]

    Reject one or several received messages.

    Reject one or several received messages.

    See also

    com.rabbitmq.client.Channel#basicNack(long, boolean, boolean)

  10. def basicPublishL(exchange: String, routingKey: String, message: JsonObject): Task[Unit]

    Publish a message.

    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

    com.rabbitmq.client.Channel#basicPublish(String, String, AMQP.BasicProperties, byte[])

  11. def basicQosL(prefetchSize: Int, prefetchCount: Int, global: Boolean): Task[Unit]

    Request specific "quality of service" settings.

    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.

    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

    See also

    com.rabbitmq.client.AMQP.Basic.Qos

  12. def basicQosL(prefetchCount: Int, global: Boolean): Task[Unit]

    Request a specific prefetchCount "quality of service" settings for this channel.

    Request a specific prefetchCount "quality of service" settings for this channel.

    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

    See also

    #basicQos(int, int, boolean, Handler)

  13. def basicQosL(prefetchCount: Int): Task[Unit]

    Request a specific prefetchCount "quality of service" settings for this channel.

    Request a specific prefetchCount "quality of service" settings for this channel.

    prefetchCount

    maximum number of messages that the server will deliver, 0 if unlimited

    See also

    #basicQos(int, int, boolean, Handler)

  14. def confirmSelectL(): Task[Unit]

    Enables publisher acknowledgements on this channel.

    Enables publisher acknowledgements on this channel. Can be called once during client initialisation. Calls to basicPublish() will have to be confirmed.

    See also

    Channel#confirmSelect()

    http://www.rabbitmq.com/confirms.html

  15. def exchangeBindL(destination: String, source: String, routingKey: String): Task[Unit]

    Bind an exchange to an exchange.

    Bind an exchange to an exchange.

    See also

    com.rabbitmq.client.Channel#exchangeBind(String, String, String)

  16. def exchangeDeclareL(exchange: String, type: String, durable: Boolean, autoDelete: Boolean, config: JsonObject): Task[Unit]

    Declare an exchange with additional parameters such as dead lettering, an alternate exchange or TTL.

    Declare an exchange with additional parameters such as dead lettering, an alternate exchange or TTL.

    See also

    com.rabbitmq.client.Channel#exchangeDeclare(String, String, boolean, boolean, Map)

  17. def exchangeDeclareL(exchange: String, type: String, durable: Boolean, autoDelete: Boolean): Task[Unit]

    Declare an exchange.

    Declare an exchange.

    See also

    com.rabbitmq.client.Channel#exchangeDeclare(String, String, boolean, boolean, Map)

  18. def exchangeDeleteL(exchange: String): Task[Unit]

    Delete an exchange, without regard for whether it is in use or not.

    Delete an exchange, without regard for whether it is in use or not.

    See also

    com.rabbitmq.client.Channel#exchangeDelete(String)

  19. def exchangeUnbindL(destination: String, source: String, routingKey: String): Task[Unit]

    Unbind an exchange from an exchange.

    Unbind an exchange from an exchange.

    See also

    com.rabbitmq.client.Channel#exchangeUnbind(String, String, String)

  20. def getClass(): Class[_ <: AnyVal]
    Definition Classes
    AnyVal → Any
  21. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  22. def messageCountL(queue: String): Task[Long]

    Returns the number of messages in a queue ready to be delivered.

    Returns the number of messages in a queue ready to be delivered.

    See also

    com.rabbitmq.client.Channel#messageCount(String)

  23. def queueBindL(queue: String, exchange: String, routingKey: String): Task[Unit]

    Bind a queue to an exchange

    Bind a queue to an exchange

    See also

    com.rabbitmq.client.Channel#queueBind(String, String, String)

  24. def queueDeclareAutoL(): Task[JsonObject]

    Actively declare a server-named exclusive, autodelete, non-durable queue.

    Actively declare a server-named exclusive, autodelete, non-durable queue.

    See also

    com.rabbitmq.client.Channel#queueDeclare()

  25. def queueDeclareL(queue: String, durable: Boolean, exclusive: Boolean, autoDelete: Boolean, config: JsonObject): Task[JsonObject]

    Declare a queue with config options

    Declare a queue with config options

    See also

    com.rabbitmq.client.Channel#queueDeclare(String, boolean, boolean, boolean, java.util.Map)

  26. def queueDeclareL(queue: String, durable: Boolean, exclusive: Boolean, autoDelete: Boolean): Task[JsonObject]

    Declare a queue

    Declare a queue

    See also

    com.rabbitmq.client.Channel#queueDeclare(String, boolean, boolean, boolean, java.util.Map)

  27. def queueDeleteIfL(queue: String, ifUnused: Boolean, ifEmpty: Boolean): Task[JsonObject]

    Delete a queue

    Delete a queue

    See also

    com.rabbitmq.client.Channel#queueDelete(String, boolean, boolean)

  28. def queueDeleteL(queue: String): Task[JsonObject]

    Delete a queue, without regard for whether it is in use or has messages on it

    Delete a queue, without regard for whether it is in use or has messages on it

    See also

    com.rabbitmq.client.Channel#queueDelete(String)

  29. def startL(): Task[Unit]

    Start the rabbitMQ client.

    Start the rabbitMQ client. Create the connection and the chanel.

    See also

    com.rabbitmq.client.Connection#createChannel()

  30. def stopL(): Task[Unit]

    Stop the rabbitMQ client.

    Stop the rabbitMQ client. Close the connection and its chanel.

    See also

    com.rabbitmq.client.Connection#close()

  31. val target: RabbitMQClient
  32. def toString(): String
    Definition Classes
    Any
  33. def waitForConfirmsL(timeout: Long): Task[Unit]

    Wait until all messages published since the last call have been either ack'd or nack'd by the broker; or until timeout elapses.

    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.

    Exceptions thrown

    java.io.IOException Throws an IOException if the message was not written to the queue.

    See also

    io.vertx.rabbitmq.impl.RabbitMQClientImpl#waitForConfirms(Handler)

    http://www.rabbitmq.com/confirms.html

  34. def waitForConfirmsL(): Task[Unit]

    Wait until all messages published since the last call have been either ack'd or nack'd by the broker.

    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.

    Exceptions thrown

    java.io.IOException Throws an IOException if the message was not written to the queue.

    See also

    Channel#waitForConfirms()

    http://www.rabbitmq.com/confirms.html

Inherited from AnyVal

Inherited from Any

Ungrouped