Packages

class RabbitMQConsumer extends ReadStream[RabbitMQMessage]

A stream of messages from a rabbitmq queue.

Linear Supertypes
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. RabbitMQConsumer
  2. ReadStream
  3. StreamBase
  4. AnyRef
  5. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new RabbitMQConsumer(_asJava: AnyRef)

Value Members

  1. final def !=(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  4. final def asInstanceOf[T0]: T0
    Definition Classes
    Any
  5. def asJava: AnyRef
    Definition Classes
    RabbitMQConsumerReadStreamStreamBase
  6. def cancel(cancelResult: Handler[AsyncResult[Unit]]): Unit

    Stop message consumption from a queue.

    Stop message consumption from a queue.

    The operation is asynchronous. When consumption will be stopped, you can by notified via io.vertx.scala.rabbitmq.RabbitMQConsumer#endHandler * @param cancelResult contains information about operation status: success/fail.

  7. def cancel(): Unit

    Stop message consumption from a queue.

    Stop message consumption from a queue.

    The operation is asynchronous. When consumption will be stopped, you can by notified via io.vertx.scala.rabbitmq.RabbitMQConsumer#endHandler

  8. def cancelFuture(): Future[Unit]

    Like cancel but returns a scala.concurrent.Future instead of taking an AsyncResultHandler.

  9. def clone(): AnyRef
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @native() @throws( ... )
  10. def consumerTag(): String

    returns

    a consumer tag

  11. def endHandler(endHandler: Handler[Unit]): RabbitMQConsumer

    Set an end handler.

    Set an end handler. Once the stream has canceled successfully, the handler will be called. * @return a reference to this, so the API can be used fluently

    Definition Classes
    RabbitMQConsumerReadStream
  12. final def eq(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  13. def equals(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  14. def exceptionHandler(exceptionHandler: Handler[Throwable]): RabbitMQConsumer

    Set an exception handler on the read stream.

    Set an exception handler on the read stream. * @param exceptionHandler the exception handler

    returns

    a reference to this, so the API can be used fluently

    Definition Classes
    RabbitMQConsumerReadStreamStreamBase
  15. def fetch(arg0: Long): ReadStream[RabbitMQMessage]

    Fetch the specified amount of elements.

    Fetch the specified amount of elements. If the ReadStream has been paused, reading will recommence with the specified amount of items, otherwise the specified amount will be added to the current stream demand. * @return a reference to this, so the API can be used fluently

    Definition Classes
    RabbitMQConsumerReadStream
  16. def finalize(): Unit
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  17. final def getClass(): Class[_]
    Definition Classes
    AnyRef → Any
    Annotations
    @native()
  18. def handler(messageArrived: Handler[RabbitMQMessage]): RabbitMQConsumer

    Set a message handler.

    Set a message handler. As message appear in a queue, the handler will be called with the message. * @return a reference to this, so the API can be used fluently

    Definition Classes
    RabbitMQConsumerReadStream
  19. def hashCode(): Int
    Definition Classes
    AnyRef → Any
    Annotations
    @native()
  20. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  21. def isPaused(): Boolean

    returns

    is the stream paused?

  22. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  23. final def notify(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native()
  24. final def notifyAll(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native()
  25. def pause(): RabbitMQConsumer

    Pause the stream of incoming messages from queue.

    Pause the stream of incoming messages from queue.

    The messages will continue to arrive, but they will be stored in a internal queue. If the queue size would exceed the limit provided by , then incoming messages will be discarded. * @return a reference to this, so the API can be used fluently

    Definition Classes
    RabbitMQConsumerReadStream
  26. def resume(): RabbitMQConsumer

    Resume reading from a queue.

    Resume reading from a queue. Flushes internal queue. * @return a reference to this, so the API can be used fluently

    Definition Classes
    RabbitMQConsumerReadStream
  27. final def synchronized[T0](arg0: ⇒ T0): T0
    Definition Classes
    AnyRef
  28. def toString(): String
    Definition Classes
    AnyRef → Any
  29. final def wait(): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  30. final def wait(arg0: Long, arg1: Int): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  31. final def wait(arg0: Long): Unit
    Definition Classes
    AnyRef
    Annotations
    @native() @throws( ... )

Inherited from ReadStream[RabbitMQMessage]

Inherited from StreamBase

Inherited from AnyRef

Inherited from Any

Ungrouped