|
|||||||||
PREV CLASS NEXT CLASS | FRAMES NO FRAMES | ||||||||
SUMMARY: NESTED | FIELD | CONSTR | METHOD | DETAIL: FIELD | CONSTR | METHOD |
public interface Channel
Public API: Interface to an AMQ channel. See the spec for details.
To open a channel,
Connection
conn = ...;Channel
channel = conn.createChannel
();
Public API:
Channel
instances are safe for use by multiple
threads. Requests into a Channel
are serialized, with only one
thread running commands at a time.
As such, applications may prefer using a Channel
per thread
instead of sharing the same Channel
across multiple threads.
An important caveat to this is that confirms are not handled
properly when a Channel
is shared between multiple threads. In that
scenario, it is therefore important to ensure that the Channel
instance is not accessed concurrently by multiple threads.
Method Summary | |
---|---|
void |
abort()
Abort this channel with the AMQP.REPLY_SUCCESS close code
and message 'OK'. |
void |
abort(int closeCode,
java.lang.String closeMessage)
Abort this channel. |
void |
addConfirmListener(ConfirmListener listener)
Add a ConfirmListener . |
void |
addFlowListener(FlowListener listener)
Add a FlowListener . |
void |
addReturnListener(ReturnListener listener)
Add a ReturnListener . |
void |
asyncRpc(Method method)
Asynchronously send a method over this channel. |
void |
basicAck(long deliveryTag,
boolean multiple)
Acknowledge one or several received messages. |
void |
basicCancel(java.lang.String consumerTag)
Cancel a consumer. |
java.lang.String |
basicConsume(java.lang.String queue,
boolean autoAck,
Consumer callback)
Start a non-nolocal, non-exclusive consumer, with a server-generated consumerTag. |
java.lang.String |
basicConsume(java.lang.String queue,
boolean autoAck,
java.lang.String consumerTag,
boolean noLocal,
boolean exclusive,
java.util.Map<java.lang.String,java.lang.Object> arguments,
Consumer callback)
Start a consumer. |
java.lang.String |
basicConsume(java.lang.String queue,
boolean autoAck,
java.lang.String consumerTag,
Consumer callback)
Start a non-nolocal, non-exclusive consumer. |
java.lang.String |
basicConsume(java.lang.String queue,
Consumer callback)
Start a non-nolocal, non-exclusive consumer, with explicit acknowledgement and a server-generated consumerTag. |
GetResponse |
basicGet(java.lang.String queue,
boolean autoAck)
Retrieve a message from a queue using AMQP.Basic.Get |
void |
basicNack(long deliveryTag,
boolean multiple,
boolean requeue)
Reject one or several received messages. |
void |
basicPublish(java.lang.String exchange,
java.lang.String routingKey,
AMQP.BasicProperties props,
byte[] body)
Publish a message |
void |
basicPublish(java.lang.String exchange,
java.lang.String routingKey,
boolean mandatory,
AMQP.BasicProperties props,
byte[] body)
Publish a message |
void |
basicPublish(java.lang.String exchange,
java.lang.String routingKey,
boolean mandatory,
boolean immediate,
AMQP.BasicProperties props,
byte[] body)
Publish a message |
void |
basicQos(int prefetchCount)
Request a specific prefetchCount "quality of service" settings for this channel. |
void |
basicQos(int prefetchSize,
int prefetchCount,
boolean global)
Request specific "quality of service" settings. |
AMQP.Basic.RecoverOk |
basicRecover()
Ask the broker to resend unacknowledged messages. |
AMQP.Basic.RecoverOk |
basicRecover(boolean requeue)
Ask the broker to resend unacknowledged messages. |
void |
basicRecoverAsync(boolean requeue)
Deprecated. |
void |
basicReject(long deliveryTag,
boolean requeue)
Reject a message. |
void |
clearConfirmListeners()
Remove all ConfirmListener s. |
void |
clearFlowListeners()
Remove all FlowListener s. |
void |
clearReturnListeners()
Remove all ReturnListener s. |
void |
close()
Close this channel with the AMQP.REPLY_SUCCESS close code
and message 'OK'. |
void |
close(int closeCode,
java.lang.String closeMessage)
Close this channel. |
AMQP.Confirm.SelectOk |
confirmSelect()
Enables publisher acknowledgements on this channel. |
AMQP.Exchange.BindOk |
exchangeBind(java.lang.String destination,
java.lang.String source,
java.lang.String routingKey)
Bind an exchange to an exchange, with no extra arguments. |
AMQP.Exchange.BindOk |
exchangeBind(java.lang.String destination,
java.lang.String source,
java.lang.String routingKey,
java.util.Map<java.lang.String,java.lang.Object> arguments)
Bind an exchange to an exchange. |
AMQP.Exchange.DeclareOk |
exchangeDeclare(java.lang.String exchange,
java.lang.String type)
Actively declare a non-autodelete, non-durable exchange with no extra arguments |
AMQP.Exchange.DeclareOk |
exchangeDeclare(java.lang.String exchange,
java.lang.String type,
boolean durable)
Actively declare a non-autodelete exchange with no extra arguments |
AMQP.Exchange.DeclareOk |
exchangeDeclare(java.lang.String exchange,
java.lang.String type,
boolean durable,
boolean autoDelete,
boolean internal,
java.util.Map<java.lang.String,java.lang.Object> arguments)
Declare an exchange, via an interface that allows the complete set of arguments. |
AMQP.Exchange.DeclareOk |
exchangeDeclare(java.lang.String exchange,
java.lang.String type,
boolean durable,
boolean autoDelete,
java.util.Map<java.lang.String,java.lang.Object> arguments)
Declare an exchange. |
AMQP.Exchange.DeclareOk |
exchangeDeclarePassive(java.lang.String name)
Declare an exchange passively; that is, check if the named exchange exists. |
AMQP.Exchange.DeleteOk |
exchangeDelete(java.lang.String exchange)
Delete an exchange, without regard for whether it is in use or not |
AMQP.Exchange.DeleteOk |
exchangeDelete(java.lang.String exchange,
boolean ifUnused)
Delete an exchange |
AMQP.Exchange.UnbindOk |
exchangeUnbind(java.lang.String destination,
java.lang.String source,
java.lang.String routingKey)
Unbind an exchange from an exchange, with no extra arguments. |
AMQP.Exchange.UnbindOk |
exchangeUnbind(java.lang.String destination,
java.lang.String source,
java.lang.String routingKey,
java.util.Map<java.lang.String,java.lang.Object> arguments)
Unbind an exchange from an exchange. |
AMQP.Channel.FlowOk |
flow(boolean active)
Set flow on the channel |
int |
getChannelNumber()
Retrieve this channel's channel number. |
Connection |
getConnection()
Retrieve the connection which carries this channel. |
Consumer |
getDefaultConsumer()
Get the current default consumer. |
AMQP.Channel.FlowOk |
getFlow()
Return the current Channel.Flow settings. |
long |
getNextPublishSeqNo()
When in confirm mode, returns the sequence number of the next message to be published. |
AMQP.Queue.BindOk |
queueBind(java.lang.String queue,
java.lang.String exchange,
java.lang.String routingKey)
Bind a queue to an exchange, with no extra arguments. |
AMQP.Queue.BindOk |
queueBind(java.lang.String queue,
java.lang.String exchange,
java.lang.String routingKey,
java.util.Map<java.lang.String,java.lang.Object> arguments)
Bind a queue to an exchange. |
AMQP.Queue.DeclareOk |
queueDeclare()
Actively declare a server-named exclusive, autodelete, non-durable queue. |
AMQP.Queue.DeclareOk |
queueDeclare(java.lang.String queue,
boolean durable,
boolean exclusive,
boolean autoDelete,
java.util.Map<java.lang.String,java.lang.Object> arguments)
Declare a queue |
AMQP.Queue.DeclareOk |
queueDeclarePassive(java.lang.String queue)
Declare a queue passively; i.e., check if it exists. |
AMQP.Queue.DeleteOk |
queueDelete(java.lang.String queue)
Delete a queue, without regard for whether it is in use or has messages on it |
AMQP.Queue.DeleteOk |
queueDelete(java.lang.String queue,
boolean ifUnused,
boolean ifEmpty)
Delete a queue |
AMQP.Queue.PurgeOk |
queuePurge(java.lang.String queue)
Purges the contents of the given queue. |
AMQP.Queue.UnbindOk |
queueUnbind(java.lang.String queue,
java.lang.String exchange,
java.lang.String routingKey)
Unbinds a queue from an exchange, with no extra arguments. |
AMQP.Queue.UnbindOk |
queueUnbind(java.lang.String queue,
java.lang.String exchange,
java.lang.String routingKey,
java.util.Map<java.lang.String,java.lang.Object> arguments)
Unbind a queue from an exchange. |
boolean |
removeConfirmListener(ConfirmListener listener)
Remove a ConfirmListener . |
boolean |
removeFlowListener(FlowListener listener)
Remove a FlowListener . |
boolean |
removeReturnListener(ReturnListener listener)
Remove a ReturnListener . |
Command |
rpc(Method method)
Synchronously send a method over this channel. |
void |
setDefaultConsumer(Consumer consumer)
Set the current default consumer. |
AMQP.Tx.CommitOk |
txCommit()
Commits a TX transaction on this channel. |
AMQP.Tx.RollbackOk |
txRollback()
Rolls back a TX transaction on this channel. |
AMQP.Tx.SelectOk |
txSelect()
Enables TX mode on this channel. |
boolean |
waitForConfirms()
Wait until all messages published since the last call have been either ack'd or nack'd by the broker. |
boolean |
waitForConfirms(long timeout)
Wait until all messages published since the last call have been either ack'd or nack'd by the broker; or until timeout elapses. |
void |
waitForConfirmsOrDie()
Wait until all messages published since the last call have been either ack'd or nack'd by the broker. |
void |
waitForConfirmsOrDie(long timeout)
Wait until all messages published since the last call have been either ack'd or nack'd by the broker; or until timeout elapses. |
Methods inherited from interface com.rabbitmq.client.ShutdownNotifier |
---|
addShutdownListener, getCloseReason, isOpen, notifyListeners, removeShutdownListener |
Method Detail |
---|
int getChannelNumber()
Connection getConnection()
Connection
void close() throws java.io.IOException
AMQP.REPLY_SUCCESS
close code
and message 'OK'.
java.io.IOException
- if an error is encounteredvoid close(int closeCode, java.lang.String closeMessage) throws java.io.IOException
closeCode
- the close code (See under "Reply Codes" in the AMQP specification)closeMessage
- a message indicating the reason for closing the connection
java.io.IOException
- if an error is encounteredAMQP.Channel.FlowOk flow(boolean active) throws java.io.IOException
active
- if true, the server is asked to start sending. If false, the server is asked to stop sending.
java.io.IOException
AMQP.Channel.FlowOk getFlow()
void abort() throws java.io.IOException
AMQP.REPLY_SUCCESS
close code
and message 'OK'.
Forces the channel to close and waits for the close operation to complete.
Any encountered exceptions in the close operation are silently discarded.
java.io.IOException
void abort(int closeCode, java.lang.String closeMessage) throws java.io.IOException
java.io.IOException
void addReturnListener(ReturnListener listener)
ReturnListener
.
listener
- the listener to addboolean removeReturnListener(ReturnListener listener)
ReturnListener
.
listener
- the listener to remove
true
if the listener was found and removed,
false
otherwisevoid clearReturnListeners()
ReturnListener
s.
void addFlowListener(FlowListener listener)
FlowListener
.
listener
- the listener to addboolean removeFlowListener(FlowListener listener)
FlowListener
.
listener
- the listener to remove
true
if the listener was found and removed,
false
otherwisevoid clearFlowListeners()
FlowListener
s.
void addConfirmListener(ConfirmListener listener)
ConfirmListener
.
listener
- the listener to addboolean removeConfirmListener(ConfirmListener listener)
ConfirmListener
.
listener
- the listener to remove
true
if the listener was found and removed,
false
otherwisevoid clearConfirmListeners()
ConfirmListener
s.
Consumer getDefaultConsumer()
void setDefaultConsumer(Consumer consumer)
consumer
- the consumer to use, or null indicating "don't use one".void basicQos(int prefetchSize, int prefetchCount, boolean global) throws java.io.IOException
prefetchSize
- maximum amount of content (measured in
octets) that the server will deliver, 0 if unlimitedprefetchCount
- maximum number of messages that the server
will deliver, 0 if unlimitedglobal
- true if the settings should be applied to the
entire connection rather than just the current channel
java.io.IOException
- if an error is encounteredAMQP.Basic.Qos
void basicQos(int prefetchCount) throws java.io.IOException
prefetchCount
- maximum number of messages that the server
will deliver, 0 if unlimited
java.io.IOException
- if an error is encounteredbasicQos(int, int, boolean)
void basicPublish(java.lang.String exchange, java.lang.String routingKey, AMQP.BasicProperties props, byte[] body) throws java.io.IOException
exchange
- the exchange to publish the message toroutingKey
- the routing keyprops
- other properties for the message - routing headers etcbody
- the message body
java.io.IOException
- if an error is encounteredAMQP.Basic.Publish
void basicPublish(java.lang.String exchange, java.lang.String routingKey, boolean mandatory, AMQP.BasicProperties props, byte[] body) throws java.io.IOException
exchange
- the exchange to publish the message toroutingKey
- the routing keymandatory
- true if the 'mandatory' flag is to be setprops
- other properties for the message - routing headers etcbody
- the message body
java.io.IOException
- if an error is encounteredAMQP.Basic.Publish
void basicPublish(java.lang.String exchange, java.lang.String routingKey, boolean mandatory, boolean immediate, AMQP.BasicProperties props, byte[] body) throws java.io.IOException
exchange
- the exchange to publish the message toroutingKey
- the routing keymandatory
- true if the 'mandatory' flag is to be setimmediate
- true if the 'immediate' flag is to be
set. Note that the RabbitMQ server does not support this flag.props
- other properties for the message - routing headers etcbody
- the message body
java.io.IOException
- if an error is encounteredAMQP.Basic.Publish
AMQP.Exchange.DeclareOk exchangeDeclare(java.lang.String exchange, java.lang.String type) throws java.io.IOException
exchange
- the name of the exchangetype
- the exchange type
java.io.IOException
- if an error is encounteredAMQP.Exchange.Declare
,
AMQP.Exchange.DeclareOk
AMQP.Exchange.DeclareOk exchangeDeclare(java.lang.String exchange, java.lang.String type, boolean durable) throws java.io.IOException
exchange
- the name of the exchangetype
- the exchange typedurable
- true if we are declaring a durable exchange (the exchange will survive a server restart)
java.io.IOException
- if an error is encounteredAMQP.Exchange.Declare
,
AMQP.Exchange.DeclareOk
AMQP.Exchange.DeclareOk exchangeDeclare(java.lang.String exchange, java.lang.String type, boolean durable, boolean autoDelete, java.util.Map<java.lang.String,java.lang.Object> arguments) throws java.io.IOException
exchange
- the name of the exchangetype
- the exchange typedurable
- true if we are declaring a durable exchange (the exchange will survive a server restart)autoDelete
- true if the server should delete the exchange when it is no longer in usearguments
- other properties (construction arguments) for the exchange
java.io.IOException
- if an error is encounteredAMQP.Exchange.Declare
,
AMQP.Exchange.DeclareOk
AMQP.Exchange.DeclareOk exchangeDeclare(java.lang.String exchange, java.lang.String type, boolean durable, boolean autoDelete, boolean internal, java.util.Map<java.lang.String,java.lang.Object> arguments) throws java.io.IOException
exchange
- the name of the exchangetype
- the exchange typedurable
- true if we are declaring a durable exchange (the exchange will survive a server restart)autoDelete
- true if the server should delete the exchange when it is no longer in useinternal
- true if the exchange is internal, i.e. can't be directly
published to by a client.arguments
- other properties (construction arguments) for the exchange
java.io.IOException
- if an error is encounteredAMQP.Exchange.Declare
,
AMQP.Exchange.DeclareOk
AMQP.Exchange.DeclareOk exchangeDeclarePassive(java.lang.String name) throws java.io.IOException
name
- check the existence of an exchange named this
java.io.IOException
- the server will raise a 404 channel exception if the named exchange does not exist.AMQP.Exchange.DeleteOk exchangeDelete(java.lang.String exchange, boolean ifUnused) throws java.io.IOException
exchange
- the name of the exchangeifUnused
- true to indicate that the exchange is only to be deleted if it is unused
java.io.IOException
- if an error is encounteredAMQP.Exchange.Delete
,
AMQP.Exchange.DeleteOk
AMQP.Exchange.DeleteOk exchangeDelete(java.lang.String exchange) throws java.io.IOException
exchange
- the name of the exchange
java.io.IOException
- if an error is encounteredAMQP.Exchange.Delete
,
AMQP.Exchange.DeleteOk
AMQP.Exchange.BindOk exchangeBind(java.lang.String destination, java.lang.String source, java.lang.String routingKey) throws java.io.IOException
destination
- the name of the exchange to which messages flow across the bindingsource
- the name of the exchange from which messages flow across the bindingroutingKey
- the routine key to use for the binding
java.io.IOException
- if an error is encounteredAMQP.Exchange.Bind
,
AMQP.Exchange.BindOk
AMQP.Exchange.BindOk exchangeBind(java.lang.String destination, java.lang.String source, java.lang.String routingKey, java.util.Map<java.lang.String,java.lang.Object> arguments) throws java.io.IOException
destination
- the name of the exchange to which messages flow across the bindingsource
- the name of the exchange from which messages flow across the bindingroutingKey
- the routine key to use for the bindingarguments
- other properties (binding parameters)
java.io.IOException
- if an error is encounteredAMQP.Exchange.Bind
,
AMQP.Exchange.BindOk
AMQP.Exchange.UnbindOk exchangeUnbind(java.lang.String destination, java.lang.String source, java.lang.String routingKey) throws java.io.IOException
destination
- the name of the exchange to which messages flow across the bindingsource
- the name of the exchange from which messages flow across the bindingroutingKey
- the routine key to use for the binding
java.io.IOException
- if an error is encounteredAMQP.Exchange.Bind
,
AMQP.Exchange.BindOk
AMQP.Exchange.UnbindOk exchangeUnbind(java.lang.String destination, java.lang.String source, java.lang.String routingKey, java.util.Map<java.lang.String,java.lang.Object> arguments) throws java.io.IOException
destination
- the name of the exchange to which messages flow across the bindingsource
- the name of the exchange from which messages flow across the bindingroutingKey
- the routine key to use for the bindingarguments
- other properties (binding parameters)
java.io.IOException
- if an error is encounteredAMQP.Exchange.Bind
,
AMQP.Exchange.BindOk
AMQP.Queue.DeclareOk queueDeclare() throws java.io.IOException
AMQP.Queue.DeclareOk
result.
java.io.IOException
- if an error is encounteredAMQP.Queue.Declare
,
AMQP.Queue.DeclareOk
AMQP.Queue.DeclareOk queueDeclare(java.lang.String queue, boolean durable, boolean exclusive, boolean autoDelete, java.util.Map<java.lang.String,java.lang.Object> arguments) throws java.io.IOException
queue
- the name of the queuedurable
- true if we are declaring a durable queue (the queue will survive a server restart)exclusive
- true if we are declaring an exclusive queue (restricted to this connection)autoDelete
- true if we are declaring an autodelete queue (server will delete it when no longer in use)arguments
- other properties (construction arguments) for the queue
java.io.IOException
- if an error is encounteredAMQP.Queue.Declare
,
AMQP.Queue.DeclareOk
AMQP.Queue.DeclareOk queueDeclarePassive(java.lang.String queue) throws java.io.IOException
queue
- the name of the queue
java.io.IOException
- if an error is encountered,
including if the queue does not exist and if the queue is
exclusively owned by another connection.AMQP.Queue.Declare
,
AMQP.Queue.DeclareOk
AMQP.Queue.DeleteOk queueDelete(java.lang.String queue) throws java.io.IOException
queue
- the name of the queue
java.io.IOException
- if an error is encounteredAMQP.Queue.Delete
,
AMQP.Queue.DeleteOk
AMQP.Queue.DeleteOk queueDelete(java.lang.String queue, boolean ifUnused, boolean ifEmpty) throws java.io.IOException
queue
- the name of the queueifUnused
- true if the queue should be deleted only if not in useifEmpty
- true if the queue should be deleted only if empty
java.io.IOException
- if an error is encounteredAMQP.Queue.Delete
,
AMQP.Queue.DeleteOk
AMQP.Queue.BindOk queueBind(java.lang.String queue, java.lang.String exchange, java.lang.String routingKey) throws java.io.IOException
queue
- the name of the queueexchange
- the name of the exchangeroutingKey
- the routine key to use for the binding
java.io.IOException
- if an error is encounteredAMQP.Queue.Bind
,
AMQP.Queue.BindOk
AMQP.Queue.BindOk queueBind(java.lang.String queue, java.lang.String exchange, java.lang.String routingKey, java.util.Map<java.lang.String,java.lang.Object> arguments) throws java.io.IOException
queue
- the name of the queueexchange
- the name of the exchangeroutingKey
- the routine key to use for the bindingarguments
- other properties (binding parameters)
java.io.IOException
- if an error is encounteredAMQP.Queue.Bind
,
AMQP.Queue.BindOk
AMQP.Queue.UnbindOk queueUnbind(java.lang.String queue, java.lang.String exchange, java.lang.String routingKey) throws java.io.IOException
queue
- the name of the queueexchange
- the name of the exchangeroutingKey
- the routine key to use for the binding
java.io.IOException
- if an error is encounteredAMQP.Queue.Unbind
,
AMQP.Queue.UnbindOk
AMQP.Queue.UnbindOk queueUnbind(java.lang.String queue, java.lang.String exchange, java.lang.String routingKey, java.util.Map<java.lang.String,java.lang.Object> arguments) throws java.io.IOException
queue
- the name of the queueexchange
- the name of the exchangeroutingKey
- the routine key to use for the bindingarguments
- other properties (binding parameters)
java.io.IOException
- if an error is encounteredAMQP.Queue.Unbind
,
AMQP.Queue.UnbindOk
AMQP.Queue.PurgeOk queuePurge(java.lang.String queue) throws java.io.IOException
queue
- the name of the queue
java.io.IOException
- if an error is encounteredAMQP.Queue.Purge
,
AMQP.Queue.PurgeOk
GetResponse basicGet(java.lang.String queue, boolean autoAck) throws java.io.IOException
AMQP.Basic.Get
queue
- the name of the queueautoAck
- true if the server should consider messages
acknowledged once delivered; false if the server should expect
explicit acknowledgements
GetResponse
containing the retrieved message data
java.io.IOException
- if an error is encounteredAMQP.Basic.Get
,
AMQP.Basic.GetOk
,
AMQP.Basic.GetEmpty
void basicAck(long deliveryTag, boolean multiple) throws java.io.IOException
AMQP.Basic.GetOk
or AMQP.Basic.Deliver
method
containing the received message being acknowledged.
deliveryTag
- the tag from the received AMQP.Basic.GetOk
or AMQP.Basic.Deliver
multiple
- true to acknowledge all messages up to and
including the supplied delivery tag; false to acknowledge just
the supplied delivery tag.
java.io.IOException
- if an error is encounteredAMQP.Basic.Ack
void basicNack(long deliveryTag, boolean multiple, boolean requeue) throws java.io.IOException
deliveryTag
from the AMQP.Basic.GetOk
or AMQP.Basic.GetOk
method containing the message to be rejected.
deliveryTag
- the tag from the received AMQP.Basic.GetOk
or AMQP.Basic.Deliver
multiple
- true to reject all messages up to and including
the supplied delivery tag; false to reject just the supplied
delivery tag.requeue
- true if the rejected message(s) should be requeued rather
than discarded/dead-lettered
java.io.IOException
- if an error is encounteredAMQP.Basic.Nack
void basicReject(long deliveryTag, boolean requeue) throws java.io.IOException
AMQP.Basic.GetOk
or AMQP.Basic.Deliver
method
containing the received message being rejected.
deliveryTag
- the tag from the received AMQP.Basic.GetOk
or AMQP.Basic.Deliver
requeue
- true if the rejected message should be requeued rather than discarded/dead-lettered
java.io.IOException
- if an error is encounteredAMQP.Basic.Reject
java.lang.String basicConsume(java.lang.String queue, Consumer callback) throws java.io.IOException
queue
- the name of the queuecallback
- an interface to the consumer object
java.io.IOException
- if an error is encounteredAMQP.Basic.Consume
,
AMQP.Basic.ConsumeOk
,
basicAck(long, boolean)
,
basicConsume(String, boolean, String, boolean, boolean, Map, Consumer)
java.lang.String basicConsume(java.lang.String queue, boolean autoAck, Consumer callback) throws java.io.IOException
queue
- the name of the queueautoAck
- true if the server should consider messages
acknowledged once delivered; false if the server should expect
explicit acknowledgementscallback
- an interface to the consumer object
java.io.IOException
- if an error is encounteredAMQP.Basic.Consume
,
AMQP.Basic.ConsumeOk
,
basicConsume(String, boolean, String, boolean, boolean, Map, Consumer)
java.lang.String basicConsume(java.lang.String queue, boolean autoAck, java.lang.String consumerTag, Consumer callback) throws java.io.IOException
queue
- the name of the queueautoAck
- true if the server should consider messages
acknowledged once delivered; false if the server should expect
explicit acknowledgementsconsumerTag
- a client-generated consumer tag to establish contextcallback
- an interface to the consumer object
java.io.IOException
- if an error is encounteredAMQP.Basic.Consume
,
AMQP.Basic.ConsumeOk
,
basicConsume(String, boolean, String, boolean, boolean, Map, Consumer)
java.lang.String basicConsume(java.lang.String queue, boolean autoAck, java.lang.String consumerTag, boolean noLocal, boolean exclusive, java.util.Map<java.lang.String,java.lang.Object> arguments, Consumer callback) throws java.io.IOException
Consumer.handleConsumeOk(java.lang.String)
method.
queue
- the name of the queueautoAck
- true if the server should consider messages
acknowledged once delivered; false if the server should expect
explicit acknowledgementsconsumerTag
- a client-generated consumer tag to establish contextnoLocal
- true if the server should not deliver to this consumer
messages published on this channel's connectionexclusive
- true if this is an exclusive consumercallback
- an interface to the consumer objectarguments
- a set of arguments for the consume
java.io.IOException
- if an error is encounteredAMQP.Basic.Consume
,
AMQP.Basic.ConsumeOk
void basicCancel(java.lang.String consumerTag) throws java.io.IOException
Consumer.handleCancelOk(java.lang.String)
method.
consumerTag
- a client- or server-generated consumer tag to establish context
java.io.IOException
- if an error is encountered, or if the consumerTag is unknownAMQP.Basic.Cancel
,
AMQP.Basic.CancelOk
AMQP.Basic.RecoverOk basicRecover() throws java.io.IOException
basicRecover(true)
, messages
will be requeued and possibly delivered to a different consumer.
java.io.IOException
basicRecover(boolean)
AMQP.Basic.RecoverOk basicRecover(boolean requeue) throws java.io.IOException
requeue
- If true, messages will be requeued and possibly
delivered to a different consumer. If false, messages will be
redelivered to the same consumer.
java.io.IOException
@Deprecated void basicRecoverAsync(boolean requeue) throws java.io.IOException
requeue
- If true, messages will be requeued and possibly
delivered to a different consumer. If false, messages will be
redelivered to the same consumer.
java.io.IOException
AMQP.Tx.SelectOk txSelect() throws java.io.IOException
java.io.IOException
- if an error is encounteredAMQP.Tx.Select
,
AMQP.Tx.SelectOk
AMQP.Tx.CommitOk txCommit() throws java.io.IOException
java.io.IOException
- if an error is encounteredAMQP.Tx.Commit
,
AMQP.Tx.CommitOk
AMQP.Tx.RollbackOk txRollback() throws java.io.IOException
java.io.IOException
- if an error is encounteredAMQP.Tx.Rollback
,
AMQP.Tx.RollbackOk
AMQP.Confirm.SelectOk confirmSelect() throws java.io.IOException
java.io.IOException
- if an error is encounteredAMQP.Confirm.Select
long getNextPublishSeqNo()
boolean waitForConfirms() throws java.lang.InterruptedException
java.lang.InterruptedException
boolean waitForConfirms(long timeout) throws java.lang.InterruptedException, java.util.concurrent.TimeoutException
java.lang.InterruptedException
java.util.concurrent.TimeoutException
void waitForConfirmsOrDie() throws java.io.IOException, java.lang.InterruptedException
java.io.IOException
java.lang.InterruptedException
void waitForConfirmsOrDie(long timeout) throws java.io.IOException, java.lang.InterruptedException, java.util.concurrent.TimeoutException
java.io.IOException
java.lang.InterruptedException
java.util.concurrent.TimeoutException
void asyncRpc(Method method) throws java.io.IOException
method
- method to transmit over this channel.
java.io.IOException
- Problem transmitting method.Command rpc(Method method) throws java.io.IOException
method
- method to transmit over this channel.
java.io.IOException
- Problem transmitting method.
|
|||||||||
PREV CLASS NEXT CLASS | FRAMES NO FRAMES | ||||||||
SUMMARY: NESTED | FIELD | CONSTR | METHOD | DETAIL: FIELD | CONSTR | METHOD |