class RabbitMQConsumer extends ReadStream[RabbitMQMessage]
A stream of messages from a rabbitmq queue.
- Alphabetic
- By Inheritance
- RabbitMQConsumer
- ReadStream
- StreamBase
- AnyRef
- Any
- Hide All
- Show All
- Public
- All
Instance Constructors
- new RabbitMQConsumer(_asJava: AnyRef)
Value Members
-
final
def
!=(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
-
final
def
##(): Int
- Definition Classes
- AnyRef → Any
-
final
def
==(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
-
final
def
asInstanceOf[T0]: T0
- Definition Classes
- Any
-
def
asJava: AnyRef
- Definition Classes
- RabbitMQConsumer → ReadStream → StreamBase
-
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.
-
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
-
def
cancelFuture(): Future[Unit]
Like cancel but returns a scala.concurrent.Future instead of taking an AsyncResultHandler.
-
def
clone(): AnyRef
- Attributes
- protected[java.lang]
- Definition Classes
- AnyRef
- Annotations
- @native() @throws( ... )
-
def
consumerTag(): String
- returns
a consumer tag
-
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
- RabbitMQConsumer → ReadStream
-
final
def
eq(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
-
def
equals(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
-
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
- RabbitMQConsumer → ReadStream → StreamBase
-
def
fetch(arg0: Long): ReadStream[RabbitMQMessage]
Fetch the specified
amount
of elements.Fetch the specified
amount
of elements. If theReadStream
has been paused, reading will recommence with the specifiedamount
of items, otherwise the specifiedamount
will be added to the current stream demand. * @return a reference to this, so the API can be used fluently- Definition Classes
- RabbitMQConsumer → ReadStream
-
def
finalize(): Unit
- Attributes
- protected[java.lang]
- Definition Classes
- AnyRef
- Annotations
- @throws( classOf[java.lang.Throwable] )
-
final
def
getClass(): Class[_]
- Definition Classes
- AnyRef → Any
- Annotations
- @native()
-
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
- RabbitMQConsumer → ReadStream
-
def
hashCode(): Int
- Definition Classes
- AnyRef → Any
- Annotations
- @native()
-
final
def
isInstanceOf[T0]: Boolean
- Definition Classes
- Any
-
def
isPaused(): Boolean
- returns
is the stream paused?
-
final
def
ne(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
-
final
def
notify(): Unit
- Definition Classes
- AnyRef
- Annotations
- @native()
-
final
def
notifyAll(): Unit
- Definition Classes
- AnyRef
- Annotations
- @native()
-
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
- RabbitMQConsumer → ReadStream
-
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
- RabbitMQConsumer → ReadStream
-
final
def
synchronized[T0](arg0: ⇒ T0): T0
- Definition Classes
- AnyRef
-
def
toString(): String
- Definition Classes
- AnyRef → Any
-
final
def
wait(): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws( ... )
-
final
def
wait(arg0: Long, arg1: Int): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws( ... )
-
final
def
wait(arg0: Long): Unit
- Definition Classes
- AnyRef
- Annotations
- @native() @throws( ... )