Class RabbitMQConsumer
- java.lang.Object
-
- io.vertx.reactivex.rabbitmq.RabbitMQConsumer
-
- All Implemented Interfaces:
ReadStream<RabbitMQMessage>
,StreamBase
public class RabbitMQConsumer extends Object implements ReadStream<RabbitMQMessage>
A stream of messages from a rabbitmq queue.NOTE: This class has been automatically generated from the
original
non RX-ified interface using Vert.x codegen.
-
-
Field Summary
Fields Modifier and Type Field Description static io.vertx.lang.rx.TypeArg<RabbitMQConsumer>
__TYPE_ARG
-
Constructor Summary
Constructors Constructor Description RabbitMQConsumer(RabbitMQConsumer delegate)
RabbitMQConsumer(Object delegate)
-
Method Summary
All Methods Static Methods Instance Methods Concrete Methods Modifier and Type Method Description Future<Void>
cancel()
Stop message consumption from a queue.String
consumerTag()
RabbitMQConsumer
endHandler(Handler<Void> endHandler)
Set an end handler.boolean
equals(Object o)
RabbitMQConsumer
exceptionHandler(Handler<Throwable> exceptionHandler)
Set an exception handler on the read stream.RabbitMQConsumer
fetch(long amount)
Fetch the specifiedamount
of elements.RabbitMQConsumer
getDelegate()
RabbitMQConsumer
handler(Handler<RabbitMQMessage> messageArrived)
Set a message handler.int
hashCode()
boolean
isCancelled()
Returntrue
if cancel() has been called.boolean
isPaused()
static RabbitMQConsumer
newInstance(RabbitMQConsumer arg)
RabbitMQConsumer
pause()
Pause the stream of incoming messages from queue.Pipe<RabbitMQMessage>
pipe()
Pause this stream and return a to transfer the elements of this stream to a destination .Future<Void>
pipeTo(WriteStream<RabbitMQMessage> dst)
Pipe thisReadStream
to theWriteStream
.String
queueName()
RabbitMQConsumer
resume()
Resume reading from a queue.Completable
rxCancel()
Stop message consumption from a queue.Completable
rxPipeTo(WriteStream<RabbitMQMessage> dst)
Pipe thisReadStream
to theWriteStream
.RabbitMQConsumer
setQueueName(String name)
Set the name of the queue.Flowable<RabbitMQMessage>
toFlowable()
Observable<RabbitMQMessage>
toObservable()
String
toString()
-
-
-
Field Detail
-
__TYPE_ARG
public static final io.vertx.lang.rx.TypeArg<RabbitMQConsumer> __TYPE_ARG
-
-
Constructor Detail
-
RabbitMQConsumer
public RabbitMQConsumer(RabbitMQConsumer delegate)
-
RabbitMQConsumer
public RabbitMQConsumer(Object delegate)
-
-
Method Detail
-
getDelegate
public RabbitMQConsumer getDelegate()
- Specified by:
getDelegate
in interfaceReadStream<RabbitMQMessage>
- Specified by:
getDelegate
in interfaceStreamBase
-
toObservable
public Observable<RabbitMQMessage> toObservable()
- Specified by:
toObservable
in interfaceReadStream<RabbitMQMessage>
-
toFlowable
public Flowable<RabbitMQMessage> toFlowable()
- Specified by:
toFlowable
in interfaceReadStream<RabbitMQMessage>
-
pipe
public Pipe<RabbitMQMessage> pipe()
Pause this stream and return a to transfer the elements of this stream to a destination . The stream will be resumed when the pipe will be wired to aWriteStream
.- Specified by:
pipe
in interfaceReadStream<RabbitMQMessage>
- Returns:
- a pipe
-
pipeTo
public Future<Void> pipeTo(WriteStream<RabbitMQMessage> dst)
Pipe thisReadStream
to theWriteStream
.Elements emitted by this stream will be written to the write stream until this stream ends or fails.
- Specified by:
pipeTo
in interfaceReadStream<RabbitMQMessage>
- Parameters:
dst
- the destination write stream- Returns:
- a future notified when the write stream will be ended with the outcome
-
rxPipeTo
public Completable rxPipeTo(WriteStream<RabbitMQMessage> dst)
Pipe thisReadStream
to theWriteStream
.Elements emitted by this stream will be written to the write stream until this stream ends or fails.
- Specified by:
rxPipeTo
in interfaceReadStream<RabbitMQMessage>
- Parameters:
dst
- the destination write stream- Returns:
- a future notified when the write stream will be ended with the outcome
-
exceptionHandler
public RabbitMQConsumer exceptionHandler(Handler<Throwable> exceptionHandler)
Set an exception handler on the read stream.- Specified by:
exceptionHandler
in interfaceReadStream<RabbitMQMessage>
- Specified by:
exceptionHandler
in interfaceStreamBase
- Parameters:
exceptionHandler
- the exception handler- Returns:
- a reference to this, so the API can be used fluently
-
handler
public RabbitMQConsumer handler(Handler<RabbitMQMessage> messageArrived)
Set a message handler. As message appear in a queue, the handler will be called with the message.- Specified by:
handler
in interfaceReadStream<RabbitMQMessage>
- Parameters:
messageArrived
-- Returns:
- a reference to this, so the API can be used fluently
-
pause
public RabbitMQConsumer pause()
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.
- Specified by:
pause
in interfaceReadStream<RabbitMQMessage>
- Returns:
- a reference to this, so the API can be used fluently
-
resume
public RabbitMQConsumer resume()
Resume reading from a queue. Flushes internal queue.- Specified by:
resume
in interfaceReadStream<RabbitMQMessage>
- Returns:
- a reference to this, so the API can be used fluently
-
endHandler
public RabbitMQConsumer endHandler(Handler<Void> endHandler)
Set an end handler. Once the stream has canceled successfully, the handler will be called.- Specified by:
endHandler
in interfaceReadStream<RabbitMQMessage>
- Parameters:
endHandler
-- Returns:
- a reference to this, so the API can be used fluently
-
queueName
public String queueName()
- Returns:
- the name of the queue
-
setQueueName
public RabbitMQConsumer setQueueName(String name)
Set the name of the queue. This method is typically only required during a connectionEstablishedCallback when the queue name has changed.- Parameters:
name
- the name of the queue- Returns:
- a reference to this, so the API can be used fluently
-
consumerTag
public String consumerTag()
- Returns:
- a consumer tag
-
cancel
public Future<Void> cancel()
Stop message consumption from a queue.The operation is asynchronous. When consumption is stopped, you can also be notified via
endHandler(io.vertx.core.Handler<java.lang.Void>)
- Returns:
- a future through which you can find out the operation status.
-
rxCancel
public Completable rxCancel()
Stop message consumption from a queue.The operation is asynchronous. When consumption is stopped, you can also be notified via
endHandler(io.vertx.core.Handler<java.lang.Void>)
- Returns:
- a future through which you can find out the operation status.
-
isCancelled
public boolean isCancelled()
Returntrue
if cancel() has been called.- Returns:
true
if cancel() has been called.
-
isPaused
public boolean isPaused()
- Returns:
- is the stream paused?
-
fetch
public RabbitMQConsumer fetch(long amount)
Fetch the specifiedamount
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.- Specified by:
fetch
in interfaceReadStream<RabbitMQMessage>
- Parameters:
amount
-- Returns:
- a reference to this, so the API can be used fluently
-
newInstance
public static RabbitMQConsumer newInstance(RabbitMQConsumer arg)
-
-