Modifier and Type | Class and Description |
---|---|
class |
AMQChannelClosedException
AMQChannelClosedException indicates that an operation cannot be performed becauase a channel has been closed.
|
class |
AMQChannelException
AMQChannelException indicates that an error that requires the channel to be closed has occurred.
|
class |
AMQConnectionClosedException
AMQConnectionClosedException indicates that a connection has been closed.
|
class |
AMQConnectionException
AMQConnectionException indicates that an error that requires the channel to be closed has occurred.
|
class |
AMQConnectionFailureException
AMQConnectionFailureException indicates that a connection to a broker could not be formed.
|
class |
AMQDisconnectedException
AMQDisconnectedException indicates that a broker disconnected without failover.
|
class |
AMQException |
class |
AMQInternalException
InternalException encapsulates error code 541, or
AMQConstant.INTERNAL_ERROR exceptions relating to the
AMQ protocol. |
class |
AMQInvalidArgumentException
AMQInvalidArgumentException indicates that an invalid argument has been passed to an AMQP method.
|
class |
AMQInvalidRoutingKeyException
AMQInvalidRoutingKeyException indicates an error with a routing key having an invalid format.
|
class |
AMQProtocolException |
class |
AMQSecurityException
SecurityException encapsulates error code 403, or
AMQConstant.ACCESS_REFUSED exceptions relating to the
AMQ protocol. |
class |
AMQTimeoutException
AMQTimeoutException indicates that an expected response from a broker took too long.
|
class |
AMQUndeliveredException
AMQUndeliveredException indicates that a message, marked immediate or mandatory, could not be delivered.
|
class |
AMQUnresolvedAddressException
AMQUnresolvedAddressException indicates failure to resolve a socket address.
|
Modifier and Type | Method and Description |
---|---|
QpidException |
QpidException.clone() |
QpidException |
QpidException.cloneForCurrentThread()
Rethrown this exception as a new exception.
|
Modifier and Type | Class and Description |
---|---|
class |
AMQAuthenticationException
AMQAuthenticationException represents all failures to authenticate access to a broker.
|
class |
AMQNoConsumersException
AMQNoConsumersException indicates failure to pass an immediate message to a consumer.
|
class |
AMQNoRouteException
AMQNoRouteException indicates that a mandatory message could not be routed.
|
Modifier and Type | Method and Description |
---|---|
QpidException |
AMQSession_0_10.getCurrentException()
Get the latest thrown exception.
|
QpidException |
AMQSession_0_8.getLastException() |
QpidException |
AMQSession_0_10.getLastException() |
abstract QpidException |
AMQSession.getLastException() |
Modifier and Type | Method and Description |
---|---|
void |
BasicMessageConsumer.addBindingKey(AMQDestination amqd,
String routingKey) |
void |
AMQSession.addBindingKey(C consumer,
AMQDestination amqd,
String routingKey) |
void |
AMQSession.bindQueue(String queueName,
String routingKey,
Map<String,Object> arguments,
String exchangeName,
AMQDestination destination)
Binds the named queue, with the specified routing key, to the named exchange.
|
void |
AMQSession.bindQueue(String queueName,
String routingKey,
Map<String,Object> arguments,
String exchangeName,
AMQDestination destination,
boolean nowait) |
void |
AMQConnectionDelegate.closeConnection(long timeout) |
void |
AMQConnectionDelegate_0_10.closeConnection(long timeout) |
void |
AMQConnectionDelegate_8_0.closeConnection(long timeout) |
void |
AMQProtocolHandler.closeConnection(long timeout)
Closes the connection.
|
void |
AMQProtocolHandler.closeSession(AMQSession session) |
void |
AMQSession_0_8.commitImpl() |
void |
AMQSession_0_10.commitImpl() |
protected abstract void |
AMQSession.commitImpl() |
void |
AMQSession.createQueue(String name,
boolean autoDelete,
boolean durable,
boolean exclusive)
Declares the named queue.
|
void |
AMQSession.createQueue(String name,
boolean autoDelete,
boolean durable,
boolean exclusive,
Map<String,Object> arguments)
Declares the named queue.
|
StateWaiter |
AMQProtocolHandler.createWaiter(Set<AMQState> states) |
void |
AMQSession.declareAndBind(AMQDestination amqd) |
void |
AMQSession.declareAndBind(AMQDestination amqd,
Map<String,Object> arguments) |
void |
AMQSession.declareExchange(String name,
String type,
boolean nowait) |
protected String |
AMQSession.declareQueue(AMQDestination amqd,
boolean noLocal)
Declares a queue for a JMS destination.
|
protected String |
AMQSession.declareQueue(AMQDestination amqd,
boolean noLocal,
boolean nowait) |
protected String |
AMQSession_0_8.declareQueue(AMQDestination amqd,
boolean noLocal,
boolean nowait,
boolean passive) |
protected String |
AMQSession_0_10.declareQueue(AMQDestination amqd,
boolean noLocal,
boolean nowait,
boolean passive) |
protected abstract String |
AMQSession.declareQueue(AMQDestination amqd,
boolean noLocal,
boolean nowait,
boolean passive) |
protected void |
AMQSession_0_8.doBind(AMQDestination dest,
AMQDestination.Binding binding,
String queue,
String exchange) |
protected abstract void |
AMQSession.doBind(AMQDestination dest,
AMQDestination.Binding binding,
String queue,
String exchange) |
protected void |
AMQSession_0_8.doUnbind(AMQDestination.Binding binding,
String queue,
String exchange) |
protected boolean |
AMQSession_0_8.ensureCreditForReceive() |
protected boolean |
AMQSession_0_8.exchangeExists(String exchangeName) |
long |
AMQSession.getQueueDepth(AMQDestination amqd)
Returns the number of messages currently queued for the given destination.
|
long |
AMQSession.getQueueDepth(AMQDestination amqd,
boolean sync)
Returns the number of messages currently queued by the given
destination.
|
protected void |
AMQSession_0_8.handleQueueNodeCreation(AMQDestination dest,
boolean noLocal) |
protected void |
AMQSession_0_10.handleQueueNodeCreation(AMQDestination dest,
boolean noLocal) |
protected abstract void |
AMQSession.handleQueueNodeCreation(AMQDestination dest,
boolean noLocal) |
protected boolean |
AMQSession_0_8.isBound(String exchangeName,
String queueName,
String routingKey)
Checks if a particular queue is bound to an exchange with a given key.
|
protected abstract boolean |
AMQSession.isBound(String exchangeName,
String amqQueueName,
String routingKey) |
boolean |
AMQSession_0_8.isExchangeExist(AMQDestination dest,
boolean assertNode) |
boolean |
AMQSession_0_10.isExchangeExist(AMQDestination dest,
boolean assertNode) |
abstract boolean |
AMQSession.isExchangeExist(AMQDestination dest,
boolean assertNode) |
boolean |
AMQSession_0_8.isQueueExist(AMQDestination dest,
boolean assertNode) |
boolean |
AMQSession_0_10.isQueueExist(AMQDestination dest,
boolean assertNode) |
abstract boolean |
AMQSession.isQueueExist(AMQDestination dest,
boolean assertNode) |
boolean |
AMQSession_0_8.isQueueExist(String queueName,
boolean assertNode,
boolean durable,
boolean autoDelete,
boolean exclusive,
Map<String,Object> args) |
boolean |
AMQSession_0_10.isQueueExist(String queueName,
boolean assertNode,
boolean durable,
boolean autoDelete,
boolean exclusive,
Map<String,Object> args) |
ProtocolVersion |
AMQConnectionDelegate.makeBrokerConnection(BrokerDetails brokerDetail) |
ProtocolVersion |
AMQConnectionDelegate_0_10.makeBrokerConnection(BrokerDetails brokerDetail)
Make a connection with the broker
|
ProtocolVersion |
AMQConnection.makeBrokerConnection(BrokerDetails brokerDetail) |
ProtocolVersion |
AMQConnectionDelegate_8_0.makeBrokerConnection(BrokerDetails brokerDetail) |
void |
AMQProtocolHandler.methodBodyReceived(int channelId,
AMQBody bodyFrame) |
protected CommonConnection |
PooledConnectionFactory.newConnectionInstance(ConnectionURL connectionDetails) |
protected String |
AMQSession.preprocessAddressTopic(C consumer,
String queueName) |
protected void |
AMQSession_0_8.reduceCreditAfterAcknowledge() |
protected Long |
AMQSession_0_8.requestQueueDepth(AMQDestination amqd,
boolean sync) |
protected abstract Long |
AMQSession.requestQueueDepth(AMQDestination amqd,
boolean sync) |
void |
AMQSession_0_8.resolveAddress(AMQDestination dest,
boolean isConsumer,
boolean noLocal) |
void |
AMQSession.resolveAddress(AMQDestination dest,
boolean isConsumer,
boolean noLocal)
1.
|
int |
AMQSession_0_8.resolveAddressType(AMQDestination dest) |
int |
AMQSession_0_10.resolveAddressType(AMQDestination dest) |
abstract int |
AMQSession.resolveAddressType(AMQDestination dest) |
void |
AMQConnectionDelegate.resubscribeSessions() |
void |
AMQConnectionDelegate_0_10.resubscribeSessions() |
void |
AMQConnection.resubscribeSessions() |
void |
AMQConnectionDelegate_8_0.resubscribeSessions()
For all sessions, and for all consumers in those sessions, resubscribe.
|
String |
AMQSession_0_10.send0_10QueueDeclare(AMQDestination amqd,
boolean noLocal,
boolean nowait,
boolean passive)
Declare a queue with the given queueName
|
void |
AMQSession_0_8.sendClose(long timeout) |
void |
AMQSession_0_10.sendClose(long timeout)
Close this session.
|
abstract void |
AMQSession.sendClose(long timeout) |
void |
AMQSession_0_10.sendConsume(BasicMessageConsumer_0_10 consumer,
String queueName,
boolean nowait,
int tag)
This method is invoked when a consumer is created
Registers the consumer with the broker
|
void |
AMQSession_0_8.sendConsume(BasicMessageConsumer_0_8 consumer,
String queueName,
boolean nowait,
int tag) |
abstract void |
AMQSession.sendConsume(C consumer,
String queueName,
boolean nowait,
int tag) |
void |
AMQSession_0_8.sendCreateQueue(String name,
boolean autoDelete,
boolean durable,
boolean exclusive,
Map<String,Object> arguments) |
void |
AMQSession_0_10.sendCreateQueue(String name,
boolean autoDelete,
boolean durable,
boolean exclusive,
Map<String,Object> arguments)
Create a queue with a given name.
|
abstract void |
AMQSession.sendCreateQueue(String name,
boolean autoDelete,
boolean durable,
boolean exclusive,
Map<String,Object> arguments) |
void |
AMQSession_0_8.sendExchangeDeclare(String name,
String type,
boolean nowait,
boolean durable,
boolean autoDelete,
boolean internal) |
void |
AMQSession_0_10.sendExchangeDeclare(String name,
String type,
boolean nowait,
boolean durable,
boolean autoDelete,
boolean internal)
creates an exchange if it does not already exist
|
abstract void |
AMQSession.sendExchangeDeclare(String name,
String type,
boolean nowait,
boolean durable,
boolean autoDelete,
boolean internal) |
void |
AMQSession_0_8.sendExchangeDeclare(String name,
String type,
boolean nowait,
boolean durable,
boolean autoDelete,
Map<String,Object> arguments,
boolean passive) |
void |
AMQSession_0_10.sendExchangeDeclare(String name,
String type,
boolean nowait,
boolean durable,
boolean autoDelete,
Map<String,Object> arguments,
boolean passive) |
abstract void |
AMQSession.sendExchangeDeclare(String name,
String type,
boolean nowait,
boolean durable,
boolean autoDelete,
Map<String,Object> arguments,
boolean passive) |
void |
AMQSession_0_10.sendExchangeDeclare(String name,
String type,
String alternateExchange,
Map<String,Object> args,
boolean nowait,
boolean durable,
boolean autoDelete) |
void |
AMQSession_0_8.sendExchangeDelete(String name,
boolean nowait) |
void |
AMQSession_0_10.sendExchangeDelete(String name,
boolean nowait)
deletes an exchange
|
void |
AMQSession_0_8.sendQueueBind(String queueName,
String routingKey,
Map<String,Object> arguments,
String exchangeName,
AMQDestination destination,
boolean nowait) |
void |
AMQSession_0_10.sendQueueBind(String queueName,
String routingKey,
Map<String,Object> arguments,
String exchangeName,
AMQDestination destination,
boolean nowait)
Bind a queue with an exchange.
|
abstract void |
AMQSession.sendQueueBind(String queueName,
String routingKey,
Map<String,Object> arguments,
String exchangeName,
AMQDestination destination,
boolean nowait) |
void |
AMQSession_0_8.sendQueueDelete(String queueName) |
void |
AMQSession_0_10.sendQueueDelete(String queueName)
deletes a queue
|
abstract void |
AMQSession.sendQueueDelete(String queueName) |
void |
AMQSession_0_8.sendRecover() |
void |
AMQSession_0_10.sendRecover()
This method asks the broker to redeliver all unacknowledged messages
|
protected abstract void |
AMQSession.sendRecover() |
void |
AMQSession_0_8.sendRollback() |
void |
AMQSession_0_10.sendRollback() |
abstract void |
AMQSession.sendRollback() |
void |
AMQSession_0_8.sendSuspendChannel(boolean suspend) |
void |
AMQSession_0_10.sendSuspendChannel(boolean suspend)
Activate/deactivate the message flow for all the consumers of this session.
|
abstract void |
AMQSession.sendSuspendChannel(boolean suspend) |
void |
AMQSession_0_8.setPrefetchLimits(int messagePrefetch,
long sizePrefetch) |
protected void |
AMQSession.suspendChannel(boolean suspend)
Suspends or unsuspends this session.
|
protected void |
AMQSession.suspendChannelIfNotClosing() |
void |
AMQSession_0_8.sync() |
void |
AMQSession_0_10.sync() |
abstract void |
AMQSession.sync() |
AMQMethodEvent |
AMQProtocolHandler.syncWrite(AMQFrame frame,
Class responseClass)
More convenient method to write a frame and wait for it's response.
|
AMQMethodEvent |
AMQProtocolHandler.syncWrite(AMQFrame frame,
Class responseClass,
long timeout)
More convenient method to write a frame and wait for it's response.
|
boolean |
AMQConnectionDelegate.verifyClientID() |
boolean |
AMQConnectionDelegate_0_10.verifyClientID() |
protected void |
AMQSession.verifySubject(AMQDestination dest) |
AMQMethodEvent |
AMQProtocolHandler.writeCommandFrameAndWaitForReply(AMQDataBlock frame,
BlockingMethodFrameListener listener)
Convenience method that writes a frame to the protocol session and waits for a particular response.
|
AMQMethodEvent |
AMQProtocolHandler.writeCommandFrameAndWaitForReply(AMQDataBlock frame,
BlockingMethodFrameListener listener,
long timeout)
Convenience method that writes a frame to the protocol session and waits for a particular response.
|
Constructor and Description |
---|
AMQConnection(ConnectionURL connectionURL)
TODO Some horrible stuff going on here with setting exceptions to be non-null to detect if an exception
was thrown during the connection! Intention not clear.
|
AMQConnection(String connection) |
AMQConnection(String host,
int port,
String username,
String password,
String clientName,
String virtualHost) |
AMQConnection(String broker,
String username,
String password,
String clientName,
String virtualHost) |
BasicMessageProducer(org.slf4j.Logger logger,
AMQConnection connection,
AMQDestination destination,
boolean transacted,
int channelId,
AMQSession session,
long producerId,
Boolean immediate,
Boolean mandatory) |
XAConnectionImpl(ConnectionURL connectionURL)
Create a XAConnection from a connectionURL
|
Modifier and Type | Class and Description |
---|---|
class |
ConnectionRedirectException |
Modifier and Type | Method and Description |
---|---|
boolean |
ClientMethodDispatcherImpl.dispatchAccessRequest(AccessRequestBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchAccessRequestOk(AccessRequestOkBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchBasicAck(BasicAckBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchBasicCancel(BasicCancelBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchBasicCancelOk(BasicCancelOkBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchBasicConsume(BasicConsumeBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchBasicConsumeOk(BasicConsumeOkBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchBasicDeliver(BasicDeliverBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchBasicGet(BasicGetBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchBasicGetEmpty(BasicGetEmptyBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchBasicGetOk(BasicGetOkBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchBasicPublish(BasicPublishBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchBasicQos(BasicQosBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchBasicQosOk(BasicQosOkBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchBasicRecover(BasicRecoverBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchBasicRecoverSync(BasicRecoverSyncBody basicRecoverSyncBody,
int channelId) |
boolean |
ClientMethodDispatcherImpl_0_91.dispatchBasicRecoverSync(BasicRecoverSyncBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl_8_0.dispatchBasicRecoverSync(BasicRecoverSyncBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl_0_9.dispatchBasicRecoverSync(BasicRecoverSyncBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchBasicRecoverSyncOk(BasicRecoverSyncOkBody basicRecoverSyncOkBody,
int channelId) |
boolean |
ClientMethodDispatcherImpl_0_91.dispatchBasicRecoverSyncOk(BasicRecoverSyncOkBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl_0_9.dispatchBasicRecoverSyncOk(BasicRecoverSyncOkBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchBasicReject(BasicRejectBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchBasicReturn(BasicReturnBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchChannelAlert(ChannelAlertBody channelAlertBody,
int channelId) |
boolean |
ClientMethodDispatcherImpl_0_91.dispatchChannelAlert(ChannelAlertBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl_8_0.dispatchChannelAlert(ChannelAlertBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl_0_9.dispatchChannelAlert(ChannelAlertBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchChannelClose(ChannelCloseBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchChannelCloseOk(ChannelCloseOkBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchChannelFlow(ChannelFlowBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchChannelFlowOk(ChannelFlowOkBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchChannelOpen(ChannelOpenBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchChannelOpenOk(ChannelOpenOkBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchConfirmSelect(ConfirmSelectBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchConfirmSelectOk(ConfirmSelectOkBody confirmSelectOkBody,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchConnectionClose(ConnectionCloseBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchConnectionCloseOk(ConnectionCloseOkBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchConnectionOpen(ConnectionOpenBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchConnectionOpenOk(ConnectionOpenOkBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchConnectionRedirect(ConnectionRedirectBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchConnectionSecure(ConnectionSecureBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchConnectionSecureOk(ConnectionSecureOkBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchConnectionStart(ConnectionStartBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchConnectionStartOk(ConnectionStartOkBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchConnectionTune(ConnectionTuneBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchConnectionTuneOk(ConnectionTuneOkBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchExchangeBound(ExchangeBoundBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchExchangeBoundOk(ExchangeBoundOkBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchExchangeDeclare(ExchangeDeclareBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchExchangeDeclareOk(ExchangeDeclareOkBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchExchangeDelete(ExchangeDeleteBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchExchangeDeleteOk(ExchangeDeleteOkBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchQueueBind(QueueBindBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchQueueBindOk(QueueBindOkBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchQueueDeclare(QueueDeclareBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchQueueDeclareOk(QueueDeclareOkBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchQueueDelete(QueueDeleteBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchQueueDeleteOk(QueueDeleteOkBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchQueuePurge(QueuePurgeBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchQueuePurgeOk(QueuePurgeOkBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchQueueUnbind(QueueUnbindBody queueUnbindBody,
int channelId) |
boolean |
ClientMethodDispatcherImpl_0_91.dispatchQueueUnbind(QueueUnbindBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl_8_0.dispatchQueueUnbind(QueueUnbindBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl_0_9.dispatchQueueUnbind(QueueUnbindBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchQueueUnbindOk(QueueUnbindOkBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl_0_91.dispatchQueueUnbindOk(QueueUnbindOkBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl_0_9.dispatchQueueUnbindOk(QueueUnbindOkBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchTxCommit(TxCommitBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchTxCommitOk(TxCommitOkBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchTxRollback(TxRollbackBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchTxRollbackOk(TxRollbackOkBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchTxSelect(TxSelectBody body,
int channelId) |
boolean |
ClientMethodDispatcherImpl.dispatchTxSelectOk(TxSelectOkBody body,
int channelId) |
void |
AccessRequestOkMethodHandler.methodReceived(AMQProtocolSession session,
AccessRequestOkBody method,
int channelId) |
void |
BasicCancelOkMethodHandler.methodReceived(AMQProtocolSession session,
BasicCancelOkBody body,
int channelId) |
void |
BasicDeliverMethodHandler.methodReceived(AMQProtocolSession session,
BasicDeliverBody body,
int channelId) |
void |
BasicReturnMethodHandler.methodReceived(AMQProtocolSession session,
BasicReturnBody body,
int channelId) |
void |
ChannelCloseMethodHandler.methodReceived(AMQProtocolSession session,
ChannelCloseBody method,
int channelId) |
void |
ChannelCloseOkMethodHandler.methodReceived(AMQProtocolSession session,
ChannelCloseOkBody method,
int channelId) |
void |
ChannelFlowMethodHandler.methodReceived(AMQProtocolSession session,
ChannelFlowBody body,
int channelId) |
void |
ChannelFlowOkMethodHandler.methodReceived(AMQProtocolSession session,
ChannelFlowOkBody body,
int channelId) |
void |
ConnectionCloseMethodHandler.methodReceived(AMQProtocolSession session,
ConnectionCloseBody method,
int channelId) |
void |
ConnectionRedirectMethodHandler.methodReceived(AMQProtocolSession session,
ConnectionRedirectBody method,
int channelId) |
void |
ConnectionSecureMethodHandler.methodReceived(AMQProtocolSession session,
ConnectionSecureBody body,
int channelId) |
void |
ConnectionStartMethodHandler.methodReceived(AMQProtocolSession session,
ConnectionStartBody body,
int channelId) |
void |
ExchangeBoundOkMethodHandler.methodReceived(AMQProtocolSession session,
ExchangeBoundOkBody body,
int channelId) |
void |
QueueDeleteOkMethodHandler.methodReceived(AMQProtocolSession session,
QueueDeleteOkBody body,
int channelId) |
Modifier and Type | Method and Description |
---|---|
protected AbstractJMSMessage |
AbstractJMSMessageFactory.create010MessageWithBody(long messageNbr,
MessageProperties msgProps,
DeliveryProperties deliveryProps,
Collection<QpidByteBuffer> body) |
protected AbstractJMSMessage |
AbstractJMSMessageFactory.create08MessageWithBody(long messageNbr,
ContentHeaderBody contentHeader,
String exchange,
String routingKey,
List bodies,
AMQSession_0_8.DestinationCache<AMQQueue> queueDestinationCache,
AMQSession_0_8.DestinationCache<AMQTopic> topicDestinationCache,
int addressType) |
protected AbstractJMSMessage |
Encrypted010MessageFactory.createMessage(AbstractAMQMessageDelegate delegate,
ByteBuffer data) |
protected abstract AbstractJMSMessage |
AbstractJMSMessageFactory.createMessage(AbstractAMQMessageDelegate delegate,
ByteBuffer data) |
protected AbstractJMSMessage |
AMQPEncodedListMessageFactory.createMessage(AbstractAMQMessageDelegate delegate,
ByteBuffer data) |
protected AbstractJMSMessage |
Encrypted091MessageFactory.createMessage(AbstractAMQMessageDelegate delegate,
ByteBuffer data) |
protected AbstractJMSMessage |
JMSMapMessageFactory.createMessage(AbstractAMQMessageDelegate delegate,
ByteBuffer data) |
protected AbstractJMSMessage |
JMSObjectMessageFactory.createMessage(AbstractAMQMessageDelegate delegate,
ByteBuffer data) |
protected AbstractJMSMessage |
JMSTextMessageFactory.createMessage(AbstractAMQMessageDelegate delegate,
ByteBuffer data) |
protected AbstractJMSMessage |
AMQPEncodedMapMessageFactory.createMessage(AbstractAMQMessageDelegate delegate,
ByteBuffer data) |
protected AbstractJMSMessage |
JMSBytesMessageFactory.createMessage(AbstractAMQMessageDelegate delegate,
ByteBuffer data) |
protected AbstractJMSMessage |
JMSStreamMessageFactory.createMessage(AbstractAMQMessageDelegate delegate,
ByteBuffer data) |
AbstractJMSMessage |
AbstractJMSMessageFactory.createMessage(long messageNbr,
boolean redelivered,
ContentHeaderBody contentHeader,
String exchange,
String routingKey,
List bodies,
AMQSession_0_8.DestinationCache<AMQQueue> queueDestinationCache,
AMQSession_0_8.DestinationCache<AMQTopic> topicDestinationCache,
int addressType) |
AbstractJMSMessage |
AbstractJMSMessageFactory.createMessage(long messageNbr,
boolean redelivered,
MessageProperties msgProps,
DeliveryProperties deliveryProps,
Collection<QpidByteBuffer> body) |
AbstractJMSMessage |
MessageFactoryRegistry.createMessage(long deliveryTag,
boolean redelivered,
String exchange,
String routingKey,
ContentHeaderBody contentHeader,
List bodies,
AMQSession_0_8.DestinationCache<AMQQueue> queueDestinationCache,
AMQSession_0_8.DestinationCache<AMQTopic> topicDestinationCache,
int addressType)
Create a message.
|
AbstractJMSMessage |
MessageFactoryRegistry.createMessage(MessageTransfer transfer) |
Constructor and Description |
---|
AbstractJMSMessage(AMQMessageDelegate delegate,
boolean fromReceivedData) |
Modifier and Type | Method and Description |
---|---|
AMQMethodEvent |
BlockingMethodFrameListener.blockForFrame(long timeout)
Blocks until a method is received that is handled by the delegated to method listener, or the specified timeout
has passed.
|
boolean |
AMQProtocolSession.channelClosed(int channelId,
AMQConstant code,
String text)
Called from the ChannelClose handler when a channel close frame is received.
|
void |
AMQProtocolSession.closeProtocolSession() |
void |
AMQProtocolSession.contentBodyReceived(int channelId,
ContentBody contentBody) |
void |
AMQProtocolSession.contentHeaderReceived(int channelId,
ContentHeaderBody contentHeader) |
void |
AMQProtocolSession.heartbeatBodyReceived(int channelId,
HeartbeatBody body) |
void |
AMQProtocolSession.methodFrameReceived(int channel,
AMQMethodBody amqMethodBody) |
void |
AMQProtocolSession.unprocessedMessageReceived(int channelId,
UnprocessedMessage message)
Callback invoked from the BasicDeliverMethodHandler when a message has been received.
|
Modifier and Type | Class and Description |
---|---|
class |
AMQMethodNotImplementedException |
Modifier and Type | Method and Description |
---|---|
AMQState |
StateWaiter.await()
Await for the required State to be achieved within the default timeout.
|
AMQState |
StateWaiter.await(long timeout)
Await for the required State to be achieved.
|
<B extends AMQMethodBody> |
AMQStateManager.methodReceived(AMQMethodEvent<B> evt) |
void |
StateAwareMethodListener.methodReceived(AMQProtocolSession session,
B body,
int channelId) |
Modifier and Type | Method and Description |
---|---|
Object |
BlockingWaiter.block(long timeout)
Blocks until an object is received that is handled by process, or the specified timeout
has passed.
|
Modifier and Type | Class and Description |
---|---|
class |
AMQFrameDecodingException
AMQFrameDecodingException indicates that an AMQP frame cannot be decoded because it does not have the correct
format as defined by the protocol.
|
Modifier and Type | Method and Description |
---|---|
ProtocolVersion |
ProtocolInitiation.checkVersion() |
boolean |
ServerMethodDispatcher.dispatchAccessRequest(AccessRequestBody accessRequestBody,
int channelId) |
boolean |
ClientMethodDispatcher.dispatchAccessRequestOk(AccessRequestOkBody accessRequestOkBody,
int channelId) |
boolean |
ServerMethodDispatcher.dispatchBasicAck(BasicAckBody body,
int channelId) |
boolean |
ServerMethodDispatcher.dispatchBasicCancel(BasicCancelBody body,
int channelId) |
boolean |
ClientMethodDispatcher.dispatchBasicCancelOk(BasicCancelOkBody body,
int channelId) |
boolean |
ServerMethodDispatcher.dispatchBasicConsume(BasicConsumeBody body,
int channelId) |
boolean |
ClientMethodDispatcher.dispatchBasicConsumeOk(BasicConsumeOkBody body,
int channelId) |
boolean |
ClientMethodDispatcher.dispatchBasicDeliver(BasicDeliverBody body,
int channelId) |
boolean |
ServerMethodDispatcher.dispatchBasicGet(BasicGetBody body,
int channelId) |
boolean |
ClientMethodDispatcher.dispatchBasicGetEmpty(BasicGetEmptyBody body,
int channelId) |
boolean |
ClientMethodDispatcher.dispatchBasicGetOk(BasicGetOkBody body,
int channelId) |
boolean |
ServerMethodDispatcher.dispatchBasicPublish(BasicPublishBody body,
int channelId) |
boolean |
ServerMethodDispatcher.dispatchBasicQos(BasicQosBody body,
int channelId) |
boolean |
ClientMethodDispatcher.dispatchBasicQosOk(BasicQosOkBody body,
int channelId) |
boolean |
ServerMethodDispatcher.dispatchBasicRecover(BasicRecoverBody body,
int channelId) |
boolean |
ServerMethodDispatcher.dispatchBasicRecoverSync(BasicRecoverSyncBody basicRecoverSyncBody,
int channelId) |
boolean |
ClientMethodDispatcher.dispatchBasicRecoverSyncOk(BasicRecoverSyncOkBody basicRecoverSyncOkBody,
int channelId) |
boolean |
ServerMethodDispatcher.dispatchBasicReject(BasicRejectBody body,
int channelId) |
boolean |
ClientMethodDispatcher.dispatchBasicReturn(BasicReturnBody body,
int channelId) |
boolean |
ClientMethodDispatcher.dispatchChannelAlert(ChannelAlertBody channelAlertBody,
int channelId) |
boolean |
ClientMethodDispatcher.dispatchChannelClose(ChannelCloseBody body,
int channelId) |
boolean |
ServerMethodDispatcher.dispatchChannelClose(ChannelCloseBody body,
int channelId) |
boolean |
ClientMethodDispatcher.dispatchChannelCloseOk(ChannelCloseOkBody body,
int channelId) |
boolean |
ServerMethodDispatcher.dispatchChannelCloseOk(ChannelCloseOkBody body,
int channelId) |
boolean |
ClientMethodDispatcher.dispatchChannelFlow(ChannelFlowBody body,
int channelId) |
boolean |
ServerMethodDispatcher.dispatchChannelFlow(ChannelFlowBody body,
int channelId) |
boolean |
ClientMethodDispatcher.dispatchChannelFlowOk(ChannelFlowOkBody body,
int channelId) |
boolean |
ServerMethodDispatcher.dispatchChannelFlowOk(ChannelFlowOkBody body,
int channelId) |
boolean |
ServerMethodDispatcher.dispatchChannelOpen(ChannelOpenBody body,
int channelId) |
boolean |
ClientMethodDispatcher.dispatchChannelOpenOk(ChannelOpenOkBody body,
int channelId) |
boolean |
ServerMethodDispatcher.dispatchConfirmSelect(ConfirmSelectBody confirmSelectBody,
int channelId) |
boolean |
ClientMethodDispatcher.dispatchConfirmSelectOk(ConfirmSelectOkBody confirmSelectOkBody,
int channelId) |
boolean |
ClientMethodDispatcher.dispatchConnectionClose(ConnectionCloseBody body,
int channelId) |
boolean |
ServerMethodDispatcher.dispatchConnectionClose(ConnectionCloseBody body,
int channelId) |
boolean |
ClientMethodDispatcher.dispatchConnectionCloseOk(ConnectionCloseOkBody body,
int channelId) |
boolean |
ServerMethodDispatcher.dispatchConnectionCloseOk(ConnectionCloseOkBody body,
int channelId) |
boolean |
ServerMethodDispatcher.dispatchConnectionOpen(ConnectionOpenBody body,
int channelId) |
boolean |
ClientMethodDispatcher.dispatchConnectionOpenOk(ConnectionOpenOkBody body,
int channelId) |
boolean |
ClientMethodDispatcher.dispatchConnectionRedirect(ConnectionRedirectBody connectionRedirectBody,
int channelId) |
boolean |
ClientMethodDispatcher.dispatchConnectionSecure(ConnectionSecureBody body,
int channelId) |
boolean |
ServerMethodDispatcher.dispatchConnectionSecureOk(ConnectionSecureOkBody body,
int channelId) |
boolean |
ClientMethodDispatcher.dispatchConnectionStart(ConnectionStartBody body,
int channelId) |
boolean |
ServerMethodDispatcher.dispatchConnectionStartOk(ConnectionStartOkBody body,
int channelId) |
boolean |
ClientMethodDispatcher.dispatchConnectionTune(ConnectionTuneBody body,
int channelId) |
boolean |
ServerMethodDispatcher.dispatchConnectionTuneOk(ConnectionTuneOkBody body,
int channelId) |
boolean |
ServerMethodDispatcher.dispatchExchangeBound(ExchangeBoundBody body,
int channelId) |
boolean |
ClientMethodDispatcher.dispatchExchangeBoundOk(ExchangeBoundOkBody body,
int channelId) |
boolean |
ServerMethodDispatcher.dispatchExchangeDeclare(ExchangeDeclareBody body,
int channelId) |
boolean |
ClientMethodDispatcher.dispatchExchangeDeclareOk(ExchangeDeclareOkBody body,
int channelId) |
boolean |
ServerMethodDispatcher.dispatchExchangeDelete(ExchangeDeleteBody body,
int channelId) |
boolean |
ClientMethodDispatcher.dispatchExchangeDeleteOk(ExchangeDeleteOkBody body,
int channelId) |
boolean |
ServerMethodDispatcher.dispatchQueueBind(QueueBindBody body,
int channelId) |
boolean |
ClientMethodDispatcher.dispatchQueueBindOk(QueueBindOkBody body,
int channelId) |
boolean |
ServerMethodDispatcher.dispatchQueueDeclare(QueueDeclareBody body,
int channelId) |
boolean |
ClientMethodDispatcher.dispatchQueueDeclareOk(QueueDeclareOkBody body,
int channelId) |
boolean |
ServerMethodDispatcher.dispatchQueueDelete(QueueDeleteBody body,
int channelId) |
boolean |
ClientMethodDispatcher.dispatchQueueDeleteOk(QueueDeleteOkBody body,
int channelId) |
boolean |
ServerMethodDispatcher.dispatchQueuePurge(QueuePurgeBody body,
int channelId) |
boolean |
ClientMethodDispatcher.dispatchQueuePurgeOk(QueuePurgeOkBody body,
int channelId) |
boolean |
ServerMethodDispatcher.dispatchQueueUnbind(QueueUnbindBody queueUnbindBody,
int channelId) |
boolean |
ClientMethodDispatcher.dispatchQueueUnbindOk(QueueUnbindOkBody queueUnbindOkBody,
int channelId) |
boolean |
ServerMethodDispatcher.dispatchTxCommit(TxCommitBody body,
int channelId) |
boolean |
ClientMethodDispatcher.dispatchTxCommitOk(TxCommitOkBody body,
int channelId) |
boolean |
ServerMethodDispatcher.dispatchTxRollback(TxRollbackBody body,
int channelId) |
boolean |
ClientMethodDispatcher.dispatchTxRollbackOk(TxRollbackOkBody body,
int channelId) |
boolean |
ServerMethodDispatcher.dispatchTxSelect(TxSelectBody body,
int channelId) |
boolean |
ClientMethodDispatcher.dispatchTxSelectOk(TxSelectOkBody body,
int channelId) |
boolean |
BasicGetEmptyBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
BasicRecoverSyncOkBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
QueueBindBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
ChannelOpenBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
BasicQosOkBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
ConnectionOpenBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
ChannelOpenOkBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
BasicRecoverBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
BasicNackBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
TxRollbackOkBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
ConfirmSelectOkBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
BasicCancelOkBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
ConnectionStartBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
TxSelectBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
ConnectionOpenOkBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
BasicConsumeOkBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
ChannelAlertBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
BasicGetBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
AccessRequestBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
ExchangeBoundBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
BasicGetOkBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
QueueUnbindOkBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
ConnectionTuneBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
ChannelFlowBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
BasicRejectBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
ChannelCloseBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
ConnectionRedirectBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
ExchangeDeleteBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
QueuePurgeBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
TxRollbackBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
BasicQosBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
ConnectionCloseOkBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
QueueDeleteOkBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
ChannelFlowOkBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
BasicCancelBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
TxCommitBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
ExchangeDeclareOkBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
QueueDeleteBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
AMQMethodBody.execute(MethodDispatcher methodDispatcher,
int channelId) |
boolean |
ConnectionTuneOkBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
QueueDeclareOkBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
QueueDeclareBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
QueuePurgeOkBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
ConnectionSecureOkBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
TxCommitOkBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
BasicRecoverSyncBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
QueueUnbindBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
QueueBindOkBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
ExchangeBoundOkBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
TxSelectOkBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
BasicReturnBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
ConnectionStartOkBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
BasicAckBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
ExchangeDeleteOkBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
AccessRequestOkBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
ConnectionSecureBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
BasicConsumeBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
ConnectionCloseBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
BasicPublishBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
ConfirmSelectBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
ExchangeDeclareBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
BasicDeliverBody.execute(MethodDispatcher dispatcher,
int channelId) |
boolean |
ChannelCloseOkBody.execute(MethodDispatcher dispatcher,
int channelId) |
void |
AMQMethodBodyImpl.handle(int channelId,
AMQVersionAwareProtocolSession session) |
void |
ContentBody.handle(int channelId,
AMQVersionAwareProtocolSession session) |
void |
ContentHeaderBody.handle(int channelId,
AMQVersionAwareProtocolSession session) |
void |
AMQBody.handle(int channelId,
AMQVersionAwareProtocolSession amqProtocolSession) |
void |
HeartbeatBody.handle(int channelId,
AMQVersionAwareProtocolSession session) |
Modifier and Type | Method and Description |
---|---|
void |
TopicSubscriber.addBindingKey(javax.jms.Topic topic,
String bindingKey) |
Modifier and Type | Method and Description |
---|---|
void |
AMQVersionAwareProtocolSession.contentBodyReceived(int channelId,
ContentBody body) |
void |
AMQVersionAwareProtocolSession.contentHeaderReceived(int channelId,
ContentHeaderBody body) |
void |
AMQVersionAwareProtocolSession.heartbeatBodyReceived(int channelId,
HeartbeatBody body) |
void |
AMQVersionAwareProtocolSession.methodFrameReceived(int channelId,
AMQMethodBody body) |
<B extends AMQMethodBody> |
AMQMethodListener.methodReceived(AMQMethodEvent<B> evt)
Notifies the listener that an AMQP method event has occurred.
|
Modifier and Type | Class and Description |
---|---|
class |
AMQNoMethodHandlerException
AMQNoMethodHandlerException represents the case where no method handler exists to handle an AQMP method.
|
Modifier and Type | Method and Description |
---|---|
static ConsumerTarget_0_8 |
ConsumerTarget_0_8.createNoAckTarget(AMQChannel channel,
AMQShortString consumerTag,
FieldTable filters,
FlowCreditManager creditManager,
ClientDeliveryMethod deliveryMethod,
RecordDeliveryMethod recordMethod) |
Copyright © 2006–2016 The Apache Software Foundation. All rights reserved.