A B C D E F G H I J K L M N O P Q R S T U V W X _

A

aboveThreshold(int) - Method in interface org.apache.qpid.client.util.FlowControllingBlockingQueue.ThresholdListener
 
AbstractAMQMessageDelegate - Class in org.apache.qpid.client.message
This abstract class provides exchange lookup functionality that is shared between all MessageDelegates.
AbstractAMQMessageDelegate() - Constructor for class org.apache.qpid.client.message.AbstractAMQMessageDelegate
 
AbstractBytesMessage - Class in org.apache.qpid.client.message
 
AbstractBytesMessage(AMQMessageDelegateFactory) - Constructor for class org.apache.qpid.client.message.AbstractBytesMessage
 
AbstractBytesMessage(AMQMessageDelegateFactory, ByteBuffer) - Constructor for class org.apache.qpid.client.message.AbstractBytesMessage
Construct a bytes message with existing data.
AbstractBytesMessage(AMQMessageDelegate, ByteBuffer) - Constructor for class org.apache.qpid.client.message.AbstractBytesMessage
 
AbstractBytesTypedMessage - Class in org.apache.qpid.client.message
 
AbstractBytesTypedMessage(AMQMessageDelegateFactory) - Constructor for class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
AbstractBytesTypedMessage(AMQMessageDelegateFactory, ByteBuffer) - Constructor for class org.apache.qpid.client.message.AbstractBytesTypedMessage
Construct a stream message with existing data.
AbstractBytesTypedMessage(AMQMessageDelegate, ByteBuffer) - Constructor for class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
AbstractJMSMessage - Class in org.apache.qpid.client.message
 
AbstractJMSMessage(AMQMessageDelegateFactory, ByteBuffer) - Constructor for class org.apache.qpid.client.message.AbstractJMSMessage
 
AbstractJMSMessage(AMQMessageDelegate, ByteBuffer) - Constructor for class org.apache.qpid.client.message.AbstractJMSMessage
 
AbstractJMSMessageFactory - Class in org.apache.qpid.client.message
 
AbstractJMSMessageFactory() - Constructor for class org.apache.qpid.client.message.AbstractJMSMessageFactory
 
AbstractKeyValue - Class in org.apache.qpid.collections.keyvalue
Abstract pair class to assist with creating KeyValue and Map.Entry implementations.
AbstractKeyValue(Object, Object) - Constructor for class org.apache.qpid.collections.keyvalue.AbstractKeyValue
Constructs a new pair with the specified key and given value.
AbstractMapEntry - Class in org.apache.qpid.collections.keyvalue
Abstract Pair class to assist with creating correct Map.Entry implementations.
AbstractMapEntry(Object, Object) - Constructor for class org.apache.qpid.collections.keyvalue.AbstractMapEntry
Constructs a new entry with the given key and given value.
AccessRequestOkMethodHandler - Class in org.apache.qpid.client.handler
 
AccessRequestOkMethodHandler() - Constructor for class org.apache.qpid.client.handler.AccessRequestOkMethodHandler
 
acknowledge() - Method in class org.apache.qpid.client.AMQSession
Acknowledges all unacknowledged messages on the session, for all message consumers on the session.
acknowledge() - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
acknowledge() - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
acknowledge() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
acknowledge() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
acknowledgeDelivered() - Method in class org.apache.qpid.client.BasicMessageConsumer
Acknowledge up to last message delivered (if any).
acknowledgeMessage(long, boolean) - Method in class org.apache.qpid.client.AMQSession
Acknowledge one or many messages.
acknowledgeMessage(long, boolean) - Method in class org.apache.qpid.client.AMQSession_0_10
Acknowledge one or many messages.
acknowledgeMessage(long, boolean) - Method in class org.apache.qpid.client.AMQSession_0_8
 
acknowledgeThis() - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
acknowledgeThis() - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
acknowledgeThis() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
acknowledgeThis() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
acknowledgeThis() - Method in interface org.apache.qpid.jms.Message
 
add(Object) - Method in class org.apache.qpid.client.util.FlowControllingBlockingQueue
 
add_escapes(String) - Static method in exception org.apache.qpid.filter.selector.ParseException
Used to convert raw characters to their escaped version when these raw version cannot be used as part of an ASCII string literal.
addBinding(AMQDestination.Binding) - Method in class org.apache.qpid.client.messaging.address.Node
 
addBindingKey(C, AMQDestination, String) - Method in class org.apache.qpid.client.AMQSession
 
addBindingKey(AMQDestination, String) - Method in class org.apache.qpid.client.BasicMessageConsumer
 
addBindingKey(Topic, String) - Method in class org.apache.qpid.client.TopicSubscriberAdaptor
 
addBindingKey(Topic, String) - Method in interface org.apache.qpid.jms.TopicSubscriber
 
addBrokerDetails(BrokerDetails) - Method in class org.apache.qpid.client.AMQConnectionURL
 
addBrokerDetails(BrokerDetails) - Method in interface org.apache.qpid.jms.ConnectionURL
 
addDeliveredMessage(long) - Method in class org.apache.qpid.client.AMQSession
 
addDeliveredMessage(long) - Method in class org.apache.qpid.client.AMQSession_0_10
Store non committed messages for this session With 0.10 messages are consumed with window mode, we must send a completion before the window size is reached so credits don't dry up.
addEscapes(String) - Static method in error org.apache.qpid.filter.selector.TokenMgrError
Replaces unprintable characters by their escaped (or unicode escaped) equivalents in the given string
addExpression() - Method in class org.apache.qpid.filter.selector.SelectorParser
 
addMethod(FailoverMethod) - Method in class org.apache.qpid.jms.FailoverPolicy
 
AddressHelper - Class in org.apache.qpid.client.messaging.address
Utility class for extracting information from the address class
AddressHelper(Address) - Constructor for class org.apache.qpid.client.messaging.address.AddressHelper
 
addToEnvironment(String, Object) - Method in class org.apache.qpid.jndi.ReadOnlyContext
 
addToEnvironment(String, Object) - Method in class org.apache.qpid.naming.ReadOnlyContext
 
addUnacknowledgedMessage(long) - Method in class org.apache.qpid.client.AMQSession
 
adjustBeginLineColumn(int, int) - Method in class org.apache.qpid.filter.selector.SimpleCharStream
Method to adjust line and column numbers for the start of a token.
allocateInitialBuffer() - Method in class org.apache.qpid.client.message.AbstractBytesMessage
 
ALT_EXCHANGE - Static variable in class org.apache.qpid.client.messaging.address.AddressHelper
 
AMQ_CONNECTION - Static variable in class org.apache.qpid.client.protocol.AMQProtocolSession
 
AMQ_PROTOCOL - Static variable in interface org.apache.qpid.jms.ConnectionURL
 
AMQAnyDestination - Class in org.apache.qpid.client
In order to support JMS 1.0 the Qpid implementation maps the direct exchange to JMS Queue and topic exchange to JMS Topic.
AMQAnyDestination(BindingURL) - Constructor for class org.apache.qpid.client.AMQAnyDestination
 
AMQAnyDestination(String) - Constructor for class org.apache.qpid.client.AMQAnyDestination
 
AMQAnyDestination(Address) - Constructor for class org.apache.qpid.client.AMQAnyDestination
 
AMQAnyDestination(AMQShortString, AMQShortString, AMQShortString, boolean, boolean, AMQShortString, boolean, AMQShortString[]) - Constructor for class org.apache.qpid.client.AMQAnyDestination
 
AMQAuthenticationException - Exception in org.apache.qpid.client
AMQAuthenticationException represents all failures to authenticate access to a broker.
AMQAuthenticationException(AMQConstant, String, Throwable) - Constructor for exception org.apache.qpid.client.AMQAuthenticationException
 
AMQBrokerDetails - Class in org.apache.qpid.client
 
AMQBrokerDetails() - Constructor for class org.apache.qpid.client.AMQBrokerDetails
 
AMQBrokerDetails(String) - Constructor for class org.apache.qpid.client.AMQBrokerDetails
 
AMQBrokerDetails(String, int, SSLConfiguration) - Constructor for class org.apache.qpid.client.AMQBrokerDetails
 
AMQCallbackHandler - Interface in org.apache.qpid.client.security
 
AMQConnection - Class in org.apache.qpid.client
 
AMQConnection(String, String, String, String, String) - Constructor for class org.apache.qpid.client.AMQConnection
 
AMQConnection(String, String, String, String, String, SSLConfiguration) - Constructor for class org.apache.qpid.client.AMQConnection
 
AMQConnection(String, int, String, String, String, String) - Constructor for class org.apache.qpid.client.AMQConnection
 
AMQConnection(String, int, String, String, String, String, SSLConfiguration) - Constructor for class org.apache.qpid.client.AMQConnection
 
AMQConnection(String, int, boolean, String, String, String, String, SSLConfiguration) - Constructor for class org.apache.qpid.client.AMQConnection
 
AMQConnection(String) - Constructor for class org.apache.qpid.client.AMQConnection
 
AMQConnection(String, SSLConfiguration) - Constructor for class org.apache.qpid.client.AMQConnection
 
AMQConnection(ConnectionURL, SSLConfiguration) - Constructor for class org.apache.qpid.client.AMQConnection
 
AMQConnection(String, String, String, String) - Constructor for class org.apache.qpid.client.AMQConnection
 
AMQConnection.ChannelToSessionMap - Class in org.apache.qpid.client
 
AMQConnection.ChannelToSessionMap() - Constructor for class org.apache.qpid.client.AMQConnection.ChannelToSessionMap
 
AMQConnectionDelegate - Interface in org.apache.qpid.client
 
AMQConnectionDelegate_0_10 - Class in org.apache.qpid.client
 
AMQConnectionDelegate_0_10(AMQConnection) - Constructor for class org.apache.qpid.client.AMQConnectionDelegate_0_10
 
AMQConnectionDelegate_0_9 - Class in org.apache.qpid.client
 
AMQConnectionDelegate_0_9(AMQConnection) - Constructor for class org.apache.qpid.client.AMQConnectionDelegate_0_9
 
AMQConnectionDelegate_8_0 - Class in org.apache.qpid.client
 
AMQConnectionDelegate_8_0(AMQConnection) - Constructor for class org.apache.qpid.client.AMQConnectionDelegate_8_0
 
AMQConnectionDelegate_9_1 - Class in org.apache.qpid.client
 
AMQConnectionDelegate_9_1(AMQConnection) - Constructor for class org.apache.qpid.client.AMQConnectionDelegate_9_1
 
AMQConnectionFactory - Class in org.apache.qpid.client
 
AMQConnectionFactory() - Constructor for class org.apache.qpid.client.AMQConnectionFactory
 
AMQConnectionFactory(String) - Constructor for class org.apache.qpid.client.AMQConnectionFactory
This is the Only constructor used! It is used form the context and from the JNDI objects.
AMQConnectionFactory(ConnectionURL) - Constructor for class org.apache.qpid.client.AMQConnectionFactory
This constructor is never used!
AMQConnectionFactory(String, String, String, String, String) - Constructor for class org.apache.qpid.client.AMQConnectionFactory
This constructor is never used!
AMQConnectionFactory(String, int, String) - Constructor for class org.apache.qpid.client.AMQConnectionFactory
This constructor is never used!
AMQConnectionFactory(String, int, String, String, String) - Constructor for class org.apache.qpid.client.AMQConnectionFactory
This constructor is never used!
AMQConnectionURL - Class in org.apache.qpid.client
 
AMQConnectionURL(String) - Constructor for class org.apache.qpid.client.AMQConnectionURL
 
AMQDestination - Class in org.apache.qpid.client
 
AMQDestination(Address) - Constructor for class org.apache.qpid.client.AMQDestination
 
AMQDestination(String) - Constructor for class org.apache.qpid.client.AMQDestination
 
AMQDestination(BindingURL) - Constructor for class org.apache.qpid.client.AMQDestination
 
AMQDestination(AMQShortString, AMQShortString, AMQShortString, AMQShortString) - Constructor for class org.apache.qpid.client.AMQDestination
 
AMQDestination(AMQShortString, AMQShortString, AMQShortString, AMQShortString, AMQShortString[]) - Constructor for class org.apache.qpid.client.AMQDestination
 
AMQDestination(AMQShortString, AMQShortString, AMQShortString) - Constructor for class org.apache.qpid.client.AMQDestination
 
AMQDestination(AMQShortString, AMQShortString, AMQShortString, boolean, boolean, AMQShortString) - Constructor for class org.apache.qpid.client.AMQDestination
 
AMQDestination(AMQShortString, AMQShortString, AMQShortString, boolean, boolean, AMQShortString, AMQShortString[]) - Constructor for class org.apache.qpid.client.AMQDestination
 
AMQDestination(AMQShortString, AMQShortString, AMQShortString, boolean, boolean, AMQShortString, boolean) - Constructor for class org.apache.qpid.client.AMQDestination
 
AMQDestination(AMQShortString, AMQShortString, AMQShortString, boolean, boolean, AMQShortString, boolean, AMQShortString[]) - Constructor for class org.apache.qpid.client.AMQDestination
 
AMQDestination(AMQShortString, AMQShortString, AMQShortString, boolean, boolean, AMQShortString, boolean, AMQShortString[], boolean) - Constructor for class org.apache.qpid.client.AMQDestination
 
AMQDestination.AddressOption - Enum in org.apache.qpid.client
 
AMQDestination.Binding - Class in org.apache.qpid.client
 
AMQDestination.Binding(String, String, String, Map<String, Object>) - Constructor for class org.apache.qpid.client.AMQDestination.Binding
 
AMQDestination.DestSyntax - Enum in org.apache.qpid.client
 
AMQHeadersExchange - Class in org.apache.qpid.client
A destination backed by a headers exchange
AMQHeadersExchange(BindingURL) - Constructor for class org.apache.qpid.client.AMQHeadersExchange
 
AMQHeadersExchange(String) - Constructor for class org.apache.qpid.client.AMQHeadersExchange
 
AMQHeadersExchange(AMQShortString) - Constructor for class org.apache.qpid.client.AMQHeadersExchange
 
AMQMessageDelegate - Interface in org.apache.qpid.client.message
 
AMQMessageDelegate_0_10 - Class in org.apache.qpid.client.message
This extends AbstractAMQMessageDelegate which contains common code between both the 0_8 and 0_10 Message types.
AMQMessageDelegate_0_10() - Constructor for class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
AMQMessageDelegate_0_10(MessageProperties, DeliveryProperties, long) - Constructor for class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
AMQMessageDelegate_0_8 - Class in org.apache.qpid.client.message
 
AMQMessageDelegate_0_8() - Constructor for class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
AMQMessageDelegate_0_8(long, BasicContentHeaderProperties, AMQShortString, AMQShortString) - Constructor for class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
AMQMessageDelegateFactory<D extends AMQMessageDelegate> - Interface in org.apache.qpid.client.message
 
AMQMethodNotImplementedException - Exception in org.apache.qpid.client.state
 
AMQMethodNotImplementedException(AMQMethodBody) - Constructor for exception org.apache.qpid.client.state.AMQMethodNotImplementedException
 
AMQNoConsumersException - Exception in org.apache.qpid.client
AMQNoConsumersException indicates failure to pass an immediate message to a consumer.
AMQNoConsumersException(String, Object, Throwable) - Constructor for exception org.apache.qpid.client.AMQNoConsumersException
 
AMQNoRouteException - Exception in org.apache.qpid.client
AMQNoRouteException indicates that a mandatory message could not be routed.
AMQNoRouteException(String, Object, Throwable) - Constructor for exception org.apache.qpid.client.AMQNoRouteException
 
AMQNoTransportForProtocolException - Exception in org.apache.qpid.client.transport
AMQNoTransportForProtocolException represents a connection failure where there is no transport medium to connect to the broker available.
AMQNoTransportForProtocolException(BrokerDetails, String, Throwable) - Constructor for exception org.apache.qpid.client.transport.AMQNoTransportForProtocolException
 
AMQPEncodedMapMessage - Class in org.apache.qpid.client.message
 
AMQPEncodedMapMessage(AMQMessageDelegateFactory) - Constructor for class org.apache.qpid.client.message.AMQPEncodedMapMessage
 
AMQPEncodedMapMessage(AMQMessageDelegateFactory, ByteBuffer) - Constructor for class org.apache.qpid.client.message.AMQPEncodedMapMessage
 
AMQPEncodedMapMessage(AMQMessageDelegate, ByteBuffer) - Constructor for class org.apache.qpid.client.message.AMQPEncodedMapMessage
 
AMQPEncodedMapMessageFactory - Class in org.apache.qpid.client.message
 
AMQPEncodedMapMessageFactory() - Constructor for class org.apache.qpid.client.message.AMQPEncodedMapMessageFactory
 
AmqPlainSaslClient - Class in org.apache.qpid.client.security.amqplain
Implements the "AMQPlain" authentication protocol that uses FieldTables to send username and pwd.
AmqPlainSaslClient(CallbackHandler) - Constructor for class org.apache.qpid.client.security.amqplain.AmqPlainSaslClient
 
AmqPlainSaslClientFactory - Class in org.apache.qpid.client.security.amqplain
 
AmqPlainSaslClientFactory() - Constructor for class org.apache.qpid.client.security.amqplain.AmqPlainSaslClientFactory
 
AMQProtocolHandler - Class in org.apache.qpid.client.protocol
AMQProtocolHandler is the client side protocol handler for AMQP, it handles all protocol events received from the network by MINA.
AMQProtocolHandler(AMQConnection) - Constructor for class org.apache.qpid.client.protocol.AMQProtocolHandler
Creates a new protocol handler, associated with the specified client connection instance.
AMQProtocolSession - Class in org.apache.qpid.client.protocol
Wrapper for protocol session that provides type-safe access to session attributes.
AMQProtocolSession(AMQProtocolHandler, AMQConnection) - Constructor for class org.apache.qpid.client.protocol.AMQProtocolSession
 
AMQQueue - Class in org.apache.qpid.client
 
AMQQueue(String) - Constructor for class org.apache.qpid.client.AMQQueue
 
AMQQueue(BindingURL) - Constructor for class org.apache.qpid.client.AMQQueue
Create a reference to a non temporary queue using a BindingURL object.
AMQQueue(AMQShortString, String) - Constructor for class org.apache.qpid.client.AMQQueue
Create a reference to a non temporary queue.
AMQQueue(AMQShortString, AMQShortString) - Constructor for class org.apache.qpid.client.AMQQueue
Create a reference to a non temporary queue.
AMQQueue(AMQShortString, AMQShortString, AMQShortString) - Constructor for class org.apache.qpid.client.AMQQueue
 
AMQQueue(AMQShortString, AMQShortString, AMQShortString, AMQShortString[]) - Constructor for class org.apache.qpid.client.AMQQueue
 
AMQQueue(String, String) - Constructor for class org.apache.qpid.client.AMQQueue
Create a reference to a non temporary queue.
AMQQueue(AMQConnection, String) - Constructor for class org.apache.qpid.client.AMQQueue
 
AMQQueue(AMQConnection, String, boolean) - Constructor for class org.apache.qpid.client.AMQQueue
 
AMQQueue(String, String, boolean) - Constructor for class org.apache.qpid.client.AMQQueue
Create a queue with a specified name.
AMQQueue(AMQShortString, AMQShortString, boolean) - Constructor for class org.apache.qpid.client.AMQQueue
Create a queue with a specified name.
AMQQueue(AMQShortString, AMQShortString, AMQShortString, boolean, boolean) - Constructor for class org.apache.qpid.client.AMQQueue
Create a reference to a queue.
AMQQueue(AMQShortString, AMQShortString, AMQShortString, boolean, boolean, boolean) - Constructor for class org.apache.qpid.client.AMQQueue
 
AMQQueue(AMQShortString, AMQShortString, AMQShortString, boolean, boolean, boolean, AMQShortString[]) - Constructor for class org.apache.qpid.client.AMQQueue
 
AMQQueueBrowser - Class in org.apache.qpid.client
 
AMQQueueBrowser(AMQSession, AMQQueue, String) - Constructor for class org.apache.qpid.client.AMQQueueBrowser
 
AMQQueueSessionAdaptor - Class in org.apache.qpid.client
Need this adaptor class to conform to JMS spec and throw IllegalStateException from createDurableSubscriber, unsubscribe, createTopic & createTemporaryTopic
AMQQueueSessionAdaptor(Session) - Constructor for class org.apache.qpid.client.AMQQueueSessionAdaptor
Construct an adaptor with a session to wrap
AMQSession<C extends BasicMessageConsumer,P extends BasicMessageProducer> - Class in org.apache.qpid.client

Responsibilities Collaborations
AMQSession(AMQConnection, int, boolean, int, MessageFactoryRegistry, int, int) - Constructor for class org.apache.qpid.client.AMQSession
Creates a new session on a connection.
AMQSession(AMQConnection, int, boolean, int, int, int) - Constructor for class org.apache.qpid.client.AMQSession
Creates a new session on a connection with the default message factory factory.
AMQSession.Dispatchable - Interface in org.apache.qpid.client
 
AMQSession.Dispatcher - Class in org.apache.qpid.client
Responsible for decoding a message fragment and passing it to the appropriate message consumer.
AMQSession.Dispatcher() - Constructor for class org.apache.qpid.client.AMQSession.Dispatcher
 
AMQSession.IdToConsumerMap<C extends BasicMessageConsumer> - Class in org.apache.qpid.client
 
AMQSession.IdToConsumerMap() - Constructor for class org.apache.qpid.client.AMQSession.IdToConsumerMap
 
AMQSession_0_10 - Class in org.apache.qpid.client
This is a 0.10 Session
AMQSession_0_10(Connection, AMQConnection, int, boolean, int, MessageFactoryRegistry, int, int) - Constructor for class org.apache.qpid.client.AMQSession_0_10
Creates a new session on a connection.
AMQSession_0_10(Connection, AMQConnection, int, boolean, int, int, int) - Constructor for class org.apache.qpid.client.AMQSession_0_10
Creates a new session on a connection with the default 0-10 message factory.
AMQSession_0_8 - Class in org.apache.qpid.client
 
AMQSession_0_8(AMQConnection, int, boolean, int, MessageFactoryRegistry, int, int) - Constructor for class org.apache.qpid.client.AMQSession_0_8
Creates a new session on a connection.
AMQSession_0_8(AMQConnection, int, boolean, int, int, int) - Constructor for class org.apache.qpid.client.AMQSession_0_8
Creates a new session on a connection with the default message factory factory.
AMQSession_0_8.QueueDeclareOkHandler - Class in org.apache.qpid.client
 
AMQSession_0_8.QueueDeclareOkHandler() - Constructor for class org.apache.qpid.client.AMQSession_0_8.QueueDeclareOkHandler
 
AMQSessionAdapter - Interface in org.apache.qpid.client
 
AMQSessionDirtyException - Exception in org.apache.qpid.client
AMQSessionDirtyException represents all failures to send data on a transacted session that is no longer in a state that the client expects.
AMQSessionDirtyException(String) - Constructor for exception org.apache.qpid.client.AMQSessionDirtyException
 
AMQState - Enum in org.apache.qpid.client.state
States used in the AMQ protocol.
AMQStateChangedEvent - Class in org.apache.qpid.client.state
An event that is fired when the protocol state has changed.
AMQStateChangedEvent(AMQState, AMQState) - Constructor for class org.apache.qpid.client.state.AMQStateChangedEvent
 
AMQStateListener - Interface in org.apache.qpid.client.state
 
AMQStateManager - Class in org.apache.qpid.client.state
The state manager is responsible for managing the state of the protocol session.
AMQStateManager() - Constructor for class org.apache.qpid.client.state.AMQStateManager
 
AMQStateManager(AMQProtocolSession) - Constructor for class org.apache.qpid.client.state.AMQStateManager
 
AMQStateManager(AMQState, AMQProtocolSession) - Constructor for class org.apache.qpid.client.state.AMQStateManager
 
AMQTemporaryQueue - Class in org.apache.qpid.client
AMQ implementation of a TemporaryQueue.
AMQTemporaryQueue(AMQSession) - Constructor for class org.apache.qpid.client.AMQTemporaryQueue
Create a new instance of an AMQTemporaryQueue
AMQTemporaryTopic - Class in org.apache.qpid.client
AMQ implementation of TemporaryTopic.
AMQTemporaryTopic(AMQSession) - Constructor for class org.apache.qpid.client.AMQTemporaryTopic
Create new temporary topic.
AMQTopic - Class in org.apache.qpid.client
 
AMQTopic(String) - Constructor for class org.apache.qpid.client.AMQTopic
 
AMQTopic(Address) - Constructor for class org.apache.qpid.client.AMQTopic
 
AMQTopic(BindingURL) - Constructor for class org.apache.qpid.client.AMQTopic
Constructor for use in creating a topic using a BindingURL.
AMQTopic(AMQShortString, AMQShortString, AMQShortString) - Constructor for class org.apache.qpid.client.AMQTopic
 
AMQTopic(AMQShortString, AMQShortString, AMQShortString, AMQShortString[]) - Constructor for class org.apache.qpid.client.AMQTopic
 
AMQTopic(AMQConnection, String) - Constructor for class org.apache.qpid.client.AMQTopic
 
AMQTopic(AMQShortString, String) - Constructor for class org.apache.qpid.client.AMQTopic
 
AMQTopic(AMQShortString, AMQShortString) - Constructor for class org.apache.qpid.client.AMQTopic
 
AMQTopic(AMQShortString, AMQShortString, boolean, AMQShortString, boolean) - Constructor for class org.apache.qpid.client.AMQTopic
 
AMQTopic(AMQShortString, AMQShortString, AMQShortString, boolean, boolean, AMQShortString, boolean) - Constructor for class org.apache.qpid.client.AMQTopic
 
AMQTopic(AMQShortString, AMQShortString, AMQShortString, boolean, boolean, AMQShortString, boolean, AMQShortString[]) - Constructor for class org.apache.qpid.client.AMQTopic
 
AMQTopicSessionAdaptor - Class in org.apache.qpid.client
 
AMQTopicSessionAdaptor(Session) - Constructor for class org.apache.qpid.client.AMQTopicSessionAdaptor
 
AMQTransportConnectionException - Exception in org.apache.qpid.client.transport
AMQTransportConnectionException indicates a failure to establish a connection through the transporting medium, to an AMQP broker.
AMQTransportConnectionException(AMQConstant, String, Throwable) - Constructor for exception org.apache.qpid.client.transport.AMQTransportConnectionException
 
AMQUndefinedDestination - Class in org.apache.qpid.client
 
AMQUndefinedDestination(AMQShortString, AMQShortString, AMQShortString) - Constructor for class org.apache.qpid.client.AMQUndefinedDestination
 
AMQVMBrokerCreationException - Exception in org.apache.qpid.client.vmbroker
AMQVMBrokerCreationException represents failure to create an in VM broker on the vm transport medium.
AMQVMBrokerCreationException(int) - Constructor for exception org.apache.qpid.client.vmbroker.AMQVMBrokerCreationException
Deprecated.  
AMQVMBrokerCreationException(AMQConstant, int, String, Throwable) - Constructor for exception org.apache.qpid.client.vmbroker.AMQVMBrokerCreationException
 
AND - Static variable in interface org.apache.qpid.filter.selector.SelectorParserConstants
RegularExpression Id.
andExpression() - Method in class org.apache.qpid.filter.selector.SelectorParser
 
appendData(byte[]) - Method in class org.apache.qpid.nclient.util.ByteBufferMessage
 
appendData(ByteBuffer) - Method in class org.apache.qpid.nclient.util.ByteBufferMessage
write the data from the current position up to the buffer limit
args - Variable in class org.apache.qpid.client.AMQDestination.Binding
 
ARGUMENTS - Static variable in class org.apache.qpid.client.messaging.address.AddressHelper
 
ArithmeticExpression - Class in org.apache.qpid.filter
An expression which performs an operation on two expression values
ArithmeticExpression(Expression, Expression) - Constructor for class org.apache.qpid.filter.ArithmeticExpression
 
asBoolean(int) - Method in class org.apache.qpid.filter.ComparisonExpression
 
asEnumeration() - Static method in enum org.apache.qpid.client.CustomJMSXProperty
 
asNumber(Object) - Method in class org.apache.qpid.filter.ArithmeticExpression
 
ASSERT - Static variable in class org.apache.qpid.client.messaging.address.AddressHelper
 
attainedConnection() - Method in class org.apache.qpid.jms.failover.FailoverExchangeMethod
 
attainedConnection() - Method in interface org.apache.qpid.jms.failover.FailoverMethod
Notification to the Failover method that a connection has been attained.
attainedConnection() - Method in class org.apache.qpid.jms.failover.FailoverRoundRobinServers
 
attainedConnection() - Method in class org.apache.qpid.jms.failover.FailoverSingleServer
 
attainedConnection() - Method in class org.apache.qpid.jms.failover.NoFailover
 
attainedConnection() - Method in class org.apache.qpid.jms.FailoverPolicy
Notification that connection was successful.
attemptReconnection(String, int) - Method in class org.apache.qpid.client.AMQConnection
 
attemptReconnection() - Method in class org.apache.qpid.client.AMQConnection
 
AUTO_DELETE - Static variable in class org.apache.qpid.client.messaging.address.AddressHelper
 
available - Variable in class org.apache.qpid.filter.selector.SimpleCharStream
 
await() - Method in class org.apache.qpid.client.state.StateWaiter
Await for the requried State to be achieved within the default timeout.
await(long) - Method in class org.apache.qpid.client.state.StateWaiter
Await for the requried State to be achieved.

B

backup(int) - Method in class org.apache.qpid.filter.selector.SimpleCharStream
Backup a number of characters.
BasicCancelOkMethodHandler - Class in org.apache.qpid.client.handler
 
BasicDeliverMethodHandler - Class in org.apache.qpid.client.handler
 
BasicDeliverMethodHandler() - Constructor for class org.apache.qpid.client.handler.BasicDeliverMethodHandler
 
BasicMessageConsumer<U> - Class in org.apache.qpid.client
 
BasicMessageConsumer(int, AMQConnection, AMQDestination, String, boolean, MessageFactoryRegistry, AMQSession, AMQProtocolHandler, FieldTable, int, int, boolean, int, boolean, boolean) - Constructor for class org.apache.qpid.client.BasicMessageConsumer
 
BasicMessageConsumer_0_10 - Class in org.apache.qpid.client
This is a 0.10 message consumer.
BasicMessageConsumer_0_10(int, AMQConnection, AMQDestination, String, boolean, MessageFactoryRegistry, AMQSession, AMQProtocolHandler, FieldTable, int, int, boolean, int, boolean, boolean) - Constructor for class org.apache.qpid.client.BasicMessageConsumer_0_10
 
BasicMessageConsumer_0_8 - Class in org.apache.qpid.client
 
BasicMessageConsumer_0_8(int, AMQConnection, AMQDestination, String, boolean, MessageFactoryRegistry, AMQSession, AMQProtocolHandler, FieldTable, int, int, boolean, int, boolean, boolean) - Constructor for class org.apache.qpid.client.BasicMessageConsumer_0_8
 
BasicMessageProducer - Class in org.apache.qpid.client
 
BasicMessageProducer(AMQConnection, AMQDestination, boolean, int, AMQSession, AMQProtocolHandler, long, boolean, boolean, boolean) - Constructor for class org.apache.qpid.client.BasicMessageProducer
 
BasicMessageProducer.PublishMode - Enum in org.apache.qpid.client
 
BasicMessageProducer_0_10 - Class in org.apache.qpid.client
This is a 0_10 message producer.
BasicMessageProducer_0_10(AMQConnection, AMQDestination, boolean, int, AMQSession, AMQProtocolHandler, long, boolean, boolean, boolean) - Constructor for class org.apache.qpid.client.BasicMessageProducer_0_10
 
BasicMessageProducer_0_8 - Class in org.apache.qpid.client
 
BasicMessageProducer_0_8(AMQConnection, AMQDestination, boolean, int, AMQSession, AMQProtocolHandler, long, boolean, boolean, boolean) - Constructor for class org.apache.qpid.client.BasicMessageProducer_0_8
 
BasicReturnMethodHandler - Class in org.apache.qpid.client.handler
 
BasicReturnMethodHandler() - Constructor for class org.apache.qpid.client.handler.BasicReturnMethodHandler
 
beginColumn - Variable in class org.apache.qpid.filter.selector.Token
The column number of the first character of this Token.
beginLine - Variable in class org.apache.qpid.filter.selector.Token
The line number of the first character of this Token.
BeginToken() - Method in class org.apache.qpid.filter.selector.SimpleCharStream
Start.
BETWEEN - Static variable in interface org.apache.qpid.filter.selector.SelectorParserConstants
RegularExpression Id.
BinaryExpression - Class in org.apache.qpid.filter
An expression which performs an operation on two expression values.
BinaryExpression(Expression, Expression) - Constructor for class org.apache.qpid.filter.BinaryExpression
 
bind(Name, Object) - Method in class org.apache.qpid.jndi.ReadOnlyContext
 
bind(String, Object) - Method in class org.apache.qpid.jndi.ReadOnlyContext
 
bind(Name, Object) - Method in class org.apache.qpid.naming.ReadOnlyContext
 
bind(String, Object) - Method in class org.apache.qpid.naming.ReadOnlyContext
 
bindingKey - Variable in class org.apache.qpid.client.AMQDestination.Binding
 
BINDINGS - Static variable in class org.apache.qpid.client.messaging.address.AddressHelper
 
bindings - Variable in class org.apache.qpid.jndi.ReadOnlyContext
 
bindings - Variable in class org.apache.qpid.naming.ReadOnlyContext
 
bindQueue(AMQShortString, AMQShortString, FieldTable, AMQShortString, AMQDestination) - Method in class org.apache.qpid.client.AMQSession
Binds the named queue, with the specified routing key, to the named exchange.
bindQueue(AMQShortString, AMQShortString, FieldTable, AMQShortString, AMQDestination, boolean) - Method in class org.apache.qpid.client.AMQSession
 
block(long) - Method in class org.apache.qpid.client.util.BlockingWaiter
Blocks until an object is received that is handled by process, or the specified timeout has passed.
BLOCK_COMMENT - Static variable in interface org.apache.qpid.filter.selector.SelectorParserConstants
RegularExpression Id.
blockForFrame(long) - Method in class org.apache.qpid.client.protocol.BlockingMethodFrameListener
Blocks until a method is received that is handled by the delegated to method listener, or the specified timeout has passed.
BlockingMethodFrameListener - Class in org.apache.qpid.client.protocol
BlockingMethodFrameListener is a 'rendezvous' which acts as a AMQMethodListener that delegates handling of incoming methods to a method listener implemented as a sub-class of this and hands off the processed method or error to a consumer.
BlockingMethodFrameListener(int) - Constructor for class org.apache.qpid.client.protocol.BlockingMethodFrameListener
Creates a new method listener, that filters incoming method to just those that match the specified channel id.
BlockingWaiter<T> - Class in org.apache.qpid.client.util
BlockingWaiter is a 'rendezvous' which delegates handling of incoming Objects to a listener implemented as a sub-class of this and hands off the process or error to a consumer.
BlockingWaiter() - Constructor for class org.apache.qpid.client.util.BlockingWaiter
 
blockUntilNotFailingOver() - Method in class org.apache.qpid.client.AMQConnection
If failover is taking place this will block until it has completed.
blockUntilNotFailingOver() - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
 
BOOLEAN_TYPE - Static variable in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
BooleanExpression - Interface in org.apache.qpid.filter
A BooleanExpression is an expression that always produces a Boolean result.
BrokerDetails - Interface in org.apache.qpid.jms
 
BROWSE - Static variable in class org.apache.qpid.client.messaging.address.AddressHelper
 
bufcolumn - Variable in class org.apache.qpid.filter.selector.SimpleCharStream
 
buffer - Variable in class org.apache.qpid.filter.selector.SimpleCharStream
 
bufline - Variable in class org.apache.qpid.filter.selector.SimpleCharStream
 
bufpos - Variable in class org.apache.qpid.filter.selector.SimpleCharStream
Position in buffer.
bufsize - Variable in class org.apache.qpid.filter.selector.SimpleCharStream
 
BYTE_TYPE - Static variable in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
BYTEARRAY_TYPE - Static variable in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
ByteBufferMessage - Class in org.apache.qpid.nclient.util
A Simple implementation of the message interface for small messages.
ByteBufferMessage(MessageProperties, DeliveryProperties) - Constructor for class org.apache.qpid.nclient.util.ByteBufferMessage
 
ByteBufferMessage() - Constructor for class org.apache.qpid.nclient.util.ByteBufferMessage
 
ByteBufferMessage(int) - Constructor for class org.apache.qpid.nclient.util.ByteBufferMessage
 
bytesReceived(long) - Method in class org.apache.qpid.client.AMQConnection
 
bytesReceived(long) - Method in interface org.apache.qpid.jms.ConnectionListener
Called when some bytes have been received on a connection
bytesSent(long) - Method in class org.apache.qpid.client.AMQConnection
 
bytesSent(long) - Method in interface org.apache.qpid.jms.ConnectionListener
Called when bytes have been transmitted to the server

C

CallbackHandlerRegistry - Class in org.apache.qpid.client.security
CallbackHandlerRegistry is a registry for call back handlers for user authentication and interaction during user authentication.
CAPACITY - Static variable in class org.apache.qpid.client.messaging.address.AddressHelper
 
CAPACITY_SOURCE - Static variable in class org.apache.qpid.client.messaging.address.AddressHelper
 
CAPACITY_TARGET - Static variable in class org.apache.qpid.client.messaging.address.AddressHelper
 
changeState(AMQState) - Method in class org.apache.qpid.client.state.AMQStateManager
 
channelClosed(int, AMQConstant, String) - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
Called from the ChannelClose handler when a channel close frame is received.
ChannelCloseMethodHandler - Class in org.apache.qpid.client.handler
 
ChannelCloseMethodHandler() - Constructor for class org.apache.qpid.client.handler.ChannelCloseMethodHandler
 
ChannelCloseOkMethodHandler - Class in org.apache.qpid.client.handler
 
ChannelCloseOkMethodHandler() - Constructor for class org.apache.qpid.client.handler.ChannelCloseOkMethodHandler
 
ChannelFlowMethodHandler - Class in org.apache.qpid.client.handler
 
ChannelFlowOkMethodHandler - Class in org.apache.qpid.client.handler
 
channelLimitReached() - Method in class org.apache.qpid.client.AMQConnection
 
ChannelLimitReachedException - Exception in org.apache.qpid.jms
Indicates that the maximum number of sessions per connection limit has been reached.
ChannelLimitReachedException(long) - Constructor for exception org.apache.qpid.jms.ChannelLimitReachedException
 
CHAR_TYPE - Static variable in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
checkAvailable(int) - Method in class org.apache.qpid.client.message.AbstractBytesMessage
Check that there is at least a certain number of bytes available to read
checkEqualOperand(Expression) - Static method in class org.apache.qpid.filter.ComparisonExpression
Validates that the expression can be used in == or <> expression.
checkException(Throwable) - Method in class org.apache.qpid.client.AMQConnection
 
checkException(Throwable) - Method in class org.apache.qpid.client.AMQConnectionDelegate_8_0
 
checkFlowControl() - Method in class org.apache.qpid.client.AMQSession
 
checkIdentiferFormat(CharSequence) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
checkIdentiferFormat(CharSequence) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
checkLessThanOperand(Expression) - Static method in class org.apache.qpid.filter.ComparisonExpression
Only Numeric expressions can be used in >, >=, < or <= expressions.s
checkNotClosed() - Method in class org.apache.qpid.client.AMQSession
 
checkNotClosed() - Method in class org.apache.qpid.client.Closeable
Checks if this is closed, and raises a JMSException if it is.
checkPropertyName(CharSequence) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
checkPropertyName(CharSequence) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
checkPropertyName(String) - Method in class org.apache.qpid.client.message.JMSMapMessage
 
checkReadable() - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
checkTransacted() - Method in class org.apache.qpid.client.AMQSession
 
checkTransport(String) - Static method in class org.apache.qpid.client.AMQBrokerDetails
 
checkValidTopic(Topic, boolean) - Method in class org.apache.qpid.client.AMQSession
 
checkValidTopic(Topic) - Method in class org.apache.qpid.client.AMQSession
 
checkWritable() - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
checkWritableProperties() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
checkWritableProperties() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
clear() - Method in class org.apache.qpid.client.AMQConnection.ChannelToSessionMap
 
clear() - Method in class org.apache.qpid.client.AMQSession.IdToConsumerMap
 
clear() - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
clear() - Method in class org.apache.qpid.collections.ReferenceMap
Deprecated. Clears this map.
clearBody() - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
clearBodyImpl() - Method in class org.apache.qpid.client.message.AbstractBytesMessage
 
clearBodyImpl() - Method in class org.apache.qpid.client.message.AbstractJMSMessage
This forces concrete classes to implement clearBody()
clearBodyImpl() - Method in class org.apache.qpid.client.message.JMSMapMessage
 
clearBodyImpl() - Method in class org.apache.qpid.client.message.JMSObjectMessage
 
clearBodyImpl() - Method in class org.apache.qpid.client.message.JMSTextMessage
 
clearData() - Method in class org.apache.qpid.nclient.util.ByteBufferMessage
 
clearLastException() - Method in class org.apache.qpid.client.state.AMQStateManager
 
clearProperties() - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
clearProperties() - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
clearProperties() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
clearProperties() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
clearReceiveQueue() - Method in class org.apache.qpid.client.BasicMessageConsumer
 
CLIENT_ID - Static variable in interface org.apache.qpid.jms.BrokerDetails
 
ClientMethodDispatcherImpl - Class in org.apache.qpid.client.handler
 
ClientMethodDispatcherImpl(AMQProtocolSession) - Constructor for class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
ClientMethodDispatcherImpl_0_9 - Class in org.apache.qpid.client.handler
 
ClientMethodDispatcherImpl_0_9(AMQProtocolSession) - Constructor for class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_9
 
ClientMethodDispatcherImpl_0_91 - Class in org.apache.qpid.client.handler
 
ClientMethodDispatcherImpl_0_91(AMQProtocolSession) - Constructor for class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_91
 
ClientMethodDispatcherImpl_8_0 - Class in org.apache.qpid.client.handler
 
ClientMethodDispatcherImpl_8_0(AMQProtocolSession) - Constructor for class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_8_0
 
close() - Method in class org.apache.qpid.client.AMQConnection
 
close(long) - Method in class org.apache.qpid.client.AMQConnection
 
close(List<AMQSession>, long) - Method in class org.apache.qpid.client.AMQConnection
 
close() - Method in class org.apache.qpid.client.AMQQueueBrowser
 
close() - Method in class org.apache.qpid.client.AMQQueueSessionAdaptor
 
close() - Method in class org.apache.qpid.client.AMQSession
Closes the session with no timeout.
close(long) - Method in class org.apache.qpid.client.AMQSession
Closes the session.
close() - Method in class org.apache.qpid.client.AMQSession.Dispatcher
 
close() - Method in class org.apache.qpid.client.AMQTopicSessionAdaptor
 
close() - Method in class org.apache.qpid.client.BasicMessageConsumer
 
close(boolean) - Method in class org.apache.qpid.client.BasicMessageConsumer
 
close() - Method in class org.apache.qpid.client.BasicMessageProducer
 
close() - Method in class org.apache.qpid.client.Closeable
Closes this object.
close() - Method in class org.apache.qpid.client.QueueReceiverAdaptor
 
close() - Method in class org.apache.qpid.client.QueueSenderAdapter
 
close() - Method in class org.apache.qpid.client.TopicPublisherAdapter
 
close() - Method in class org.apache.qpid.client.TopicSubscriberAdaptor
 
close() - Method in class org.apache.qpid.client.util.BlockingWaiter
Close this Waiter so that no more errors are processed.
close() - Method in class org.apache.qpid.jndi.ReadOnlyContext
 
close() - Method in class org.apache.qpid.naming.ReadOnlyContext
 
Closeable - Class in org.apache.qpid.client
Captures the 'closed' state of an object, that is initially open, can be tested to see if it is closed, and provides a 'close' method to close it.
Closeable() - Constructor for class org.apache.qpid.client.Closeable
 
closeConnection(long) - Method in interface org.apache.qpid.client.AMQConnectionDelegate
 
closeConnection(long) - Method in class org.apache.qpid.client.AMQConnectionDelegate_0_10
 
closeConnection(long) - Method in class org.apache.qpid.client.AMQConnectionDelegate_8_0
 
closeConnection(long) - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
Closes the connection.
CloseConsumerMessage - Class in org.apache.qpid.client.message
 
CloseConsumerMessage(BasicMessageConsumer) - Constructor for class org.apache.qpid.client.message.CloseConsumerMessage
 
closed(Connection) - Method in class org.apache.qpid.client.AMQConnectionDelegate_0_10
 
closed(Throwable) - Method in class org.apache.qpid.client.AMQSession
Called when the server initiates the closure of the session unilaterally.
closed(Session) - Method in class org.apache.qpid.client.AMQSession_0_10
 
closed() - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
Called when the network connection is closed.
closeProtocolSession() - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
 
closeSession(AMQSession) - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
 
closeSession(AMQSession) - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
Starts the process of closing a session
column - Variable in class org.apache.qpid.filter.selector.SimpleCharStream
 
commit() - Method in class org.apache.qpid.client.AMQQueueSessionAdaptor
 
commit() - Method in class org.apache.qpid.client.AMQSession
Commits all messages done in this transaction and releases any locks currently held.
commit() - Method in class org.apache.qpid.client.AMQSession_0_10
 
commit() - Method in class org.apache.qpid.client.AMQTopicSessionAdaptor
 
commit(Xid, boolean) - Method in class org.apache.qpid.client.XAResourceImpl
Commits the global transaction specified by xid.
commit() - Method in class org.apache.qpid.client.XASessionImpl
Throws a TransactionInProgressException, since it should not be called for an XASession object.
compare(Comparable, Comparable) - Method in class org.apache.qpid.filter.ComparisonExpression
 
ComparisonExpression - Class in org.apache.qpid.filter
A filter performing a comparison of two objects
ComparisonExpression(Expression, Expression) - Constructor for class org.apache.qpid.filter.ComparisonExpression
 
comparisonExpression() - Method in class org.apache.qpid.filter.selector.SelectorParser
 
ComparisonExpression.LikeExpression - Class in org.apache.qpid.filter
 
ComparisonExpression.LikeExpression(Expression, String, int) - Constructor for class org.apache.qpid.filter.ComparisonExpression.LikeExpression
 
composeName(Name, Name) - Method in class org.apache.qpid.jndi.ReadOnlyContext
 
composeName(String, String) - Method in class org.apache.qpid.jndi.ReadOnlyContext
 
composeName(Name, Name) - Method in class org.apache.qpid.naming.ReadOnlyContext
 
composeName(String, String) - Method in class org.apache.qpid.naming.ReadOnlyContext
 
CONFIG - Static variable in class org.apache.qpid.client.protocol.HeartbeatConfig
 
confirmConsumerCancelled(int) - Method in class org.apache.qpid.client.AMQSession
 
confirmConsumerCancelled(int, AMQShortString) - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
 
connect(SocketAddress, IoHandler, IoServiceConfig) - Method in class org.apache.mina.transport.socket.nio.ExistingSocketConnector
 
connect(SocketAddress, SocketAddress, IoHandler, IoServiceConfig) - Method in class org.apache.mina.transport.socket.nio.ExistingSocketConnector
 
connect(AMQProtocolHandler, BrokerDetails) - Method in interface org.apache.qpid.client.transport.ITransportConnection
 
connect(AMQProtocolHandler, BrokerDetails) - Method in class org.apache.qpid.client.transport.SocketTransportConnection
 
connect(AMQProtocolHandler, BrokerDetails) - Method in class org.apache.qpid.client.transport.VmPipeTransportConnection
 
connection - Variable in class org.apache.qpid.client.failover.FailoverNoopSupport
The connection on which the fail-over protected operation is to be performed.
connection - Variable in class org.apache.qpid.client.failover.FailoverRetrySupport
The connection on which the fail-over protected operation is to be performed.
Connection - Interface in org.apache.qpid.jms
 
CONNECTION_TUNE_PARAMETERS - Static variable in class org.apache.qpid.client.protocol.AMQProtocolSession
 
ConnectionCloseMethodHandler - Class in org.apache.qpid.client.handler
 
ConnectionListener - Interface in org.apache.qpid.jms
 
ConnectionOpenOkMethodHandler - Class in org.apache.qpid.client.handler
 
ConnectionRedirectMethodHandler - Class in org.apache.qpid.client.handler
 
ConnectionSecureMethodHandler - Class in org.apache.qpid.client.handler
 
ConnectionSecureMethodHandler() - Constructor for class org.apache.qpid.client.handler.ConnectionSecureMethodHandler
 
ConnectionStartMethodHandler - Class in org.apache.qpid.client.handler
 
connectionStopped() - Method in class org.apache.qpid.client.AMQSession.Dispatcher
 
ConnectionTuneMethodHandler - Class in org.apache.qpid.client.handler
 
ConnectionTuneMethodHandler() - Constructor for class org.apache.qpid.client.handler.ConnectionTuneMethodHandler
 
ConnectionTuneParameters - Class in org.apache.qpid.client
 
ConnectionTuneParameters() - Constructor for class org.apache.qpid.client.ConnectionTuneParameters
 
ConnectionURL - Interface in org.apache.qpid.jms
Connection URL format amqp://[user:pass@][clientid]/virtualhost?brokerlist='tcp://host:port?option=\'value\'&option=\'value\';vm://:3/virtualpath?option=\'value\''&failover='method?option=\'value\'&option='value''" Options are of course optional except for requiring a single broker in the broker list.
ConstantExpression - Class in org.apache.qpid.filter
Represents a constant expression
ConstantExpression(Object) - Constructor for class org.apache.qpid.filter.ConstantExpression
 
ConstantExpression.BooleanConstantExpression - Class in org.apache.qpid.filter
 
ConstantExpression.BooleanConstantExpression(Object) - Constructor for class org.apache.qpid.filter.ConstantExpression.BooleanConstantExpression
 
containsKey(Object) - Method in class org.apache.qpid.collections.ReferenceMap
Deprecated. Returns true if this map contains the given key.
contentBodyReceived(int, ContentBody) - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
 
contentHeaderReceived(int, ContentHeaderBody) - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
 
convertToFieldTable(Map<String, ?>) - Static method in class org.apache.qpid.client.message.FieldTableSupport
 
convertToMap(FieldTable) - Static method in class org.apache.qpid.client.message.FieldTableSupport
 
copyDestination() - Method in class org.apache.qpid.client.AMQDestination
 
CRAMMD5HashedSaslClientFactory - Class in org.apache.qpid.client.security.crammd5hashed
 
CRAMMD5HashedSaslClientFactory() - Constructor for class org.apache.qpid.client.security.crammd5hashed.CRAMMD5HashedSaslClientFactory
 
CREATE - Static variable in class org.apache.qpid.client.messaging.address.AddressHelper
 
create010MessageWithBody(long, MessageProperties, DeliveryProperties, ByteBuffer) - Method in class org.apache.qpid.client.message.AbstractJMSMessageFactory
 
create08MessageWithBody(long, ContentHeaderBody, AMQShortString, AMQShortString, List) - Method in class org.apache.qpid.client.message.AbstractJMSMessageFactory
 
createAND(BooleanExpression, BooleanExpression) - Static method in class org.apache.qpid.filter.LogicExpression
 
createBetween(Expression, Expression, Expression) - Static method in class org.apache.qpid.filter.ComparisonExpression
 
createBooleanCast(Expression) - Static method in class org.apache.qpid.filter.UnaryExpression
 
createBrowser(Queue) - Method in class org.apache.qpid.client.AMQQueueSessionAdaptor
 
createBrowser(Queue, String) - Method in class org.apache.qpid.client.AMQQueueSessionAdaptor
 
createBrowser(Queue) - Method in class org.apache.qpid.client.AMQSession
 
createBrowser(Queue, String) - Method in class org.apache.qpid.client.AMQSession
 
createBrowser(Queue) - Method in class org.apache.qpid.client.AMQTopicSessionAdaptor
 
createBrowser(Queue, String) - Method in class org.apache.qpid.client.AMQTopicSessionAdaptor
 
createBrowserConsumer(Destination, String, boolean) - Method in class org.apache.qpid.client.AMQSession
 
createBytesMessage() - Method in class org.apache.qpid.client.AMQQueueSessionAdaptor
 
createBytesMessage() - Method in class org.apache.qpid.client.AMQSession
 
createBytesMessage() - Method in class org.apache.qpid.client.AMQTopicSessionAdaptor
 
createConnection() - Method in class org.apache.qpid.client.AMQConnectionFactory
 
createConnection(String, String) - Method in class org.apache.qpid.client.AMQConnectionFactory
 
createConnection(String, String, String) - Method in class org.apache.qpid.client.AMQConnectionFactory
 
createConnectionConsumer(Destination, String, ServerSessionPool, int) - Method in class org.apache.qpid.client.AMQConnection
 
createConnectionConsumer(Queue, String, ServerSessionPool, int) - Method in class org.apache.qpid.client.AMQConnection
 
createConnectionConsumer(Topic, String, ServerSessionPool, int) - Method in class org.apache.qpid.client.AMQConnection
 
createConnectionFactories(Map, Hashtable) - Method in class org.apache.qpid.jndi.PropertiesFileInitialContextFactory
 
createConsumer(Destination) - Method in class org.apache.qpid.client.AMQQueueSessionAdaptor
 
createConsumer(Destination, String) - Method in class org.apache.qpid.client.AMQQueueSessionAdaptor
 
createConsumer(Destination, String, boolean) - Method in class org.apache.qpid.client.AMQQueueSessionAdaptor
 
createConsumer(Destination) - Method in class org.apache.qpid.client.AMQSession
 
createConsumer(Destination, String) - Method in class org.apache.qpid.client.AMQSession
 
createConsumer(Destination, String, boolean) - Method in class org.apache.qpid.client.AMQSession
 
createConsumer(Destination, int, boolean, boolean, String) - Method in class org.apache.qpid.client.AMQSession
 
createConsumer(Destination, int, int, boolean, boolean, String) - Method in class org.apache.qpid.client.AMQSession
 
createConsumer(Destination, int, boolean, boolean, String, FieldTable) - Method in class org.apache.qpid.client.AMQSession
 
createConsumer(Destination, int, int, boolean, boolean, String, FieldTable) - Method in class org.apache.qpid.client.AMQSession
 
createConsumer(Destination) - Method in class org.apache.qpid.client.AMQTopicSessionAdaptor
 
createConsumer(Destination, String) - Method in class org.apache.qpid.client.AMQTopicSessionAdaptor
 
createConsumer(Destination, String, boolean) - Method in class org.apache.qpid.client.AMQTopicSessionAdaptor
 
createConsumer(Destination, int, boolean, boolean, String) - Method in interface org.apache.qpid.jms.Session
 
createConsumer(Destination, int, int, boolean, boolean, String) - Method in interface org.apache.qpid.jms.Session
 
createConsumerImpl(Destination, int, int, boolean, boolean, String, FieldTable, boolean, boolean) - Method in class org.apache.qpid.client.AMQSession
 
createContext(Map, Hashtable) - Method in class org.apache.qpid.jndi.PropertiesFileInitialContextFactory
 
createDelegate() - Method in interface org.apache.qpid.client.message.AMQMessageDelegateFactory
 
createDestination(byte[]) - Static method in class org.apache.qpid.client.AMQDestination
 
createDestination(BindingURL) - Static method in class org.apache.qpid.client.AMQDestination
 
createDestination(String) - Static method in class org.apache.qpid.client.AMQDestination
 
createDestination(String) - Method in class org.apache.qpid.jndi.PropertiesFileInitialContextFactory
Factory method to create new Destination instances from an AMQP BindingURL
createDestinations(Map, Hashtable) - Method in class org.apache.qpid.jndi.PropertiesFileInitialContextFactory
 
createDivide(Expression, Expression) - Static method in class org.apache.qpid.filter.ArithmeticExpression
 
createDurableConnectionConsumer(Topic, String, String, ServerSessionPool, int) - Method in class org.apache.qpid.client.AMQConnection
 
createDurableSubscriber(Topic, String) - Method in class org.apache.qpid.client.AMQQueueSessionAdaptor
 
createDurableSubscriber(Topic, String, String, boolean) - Method in class org.apache.qpid.client.AMQQueueSessionAdaptor
 
createDurableSubscriber(Topic, String) - Method in class org.apache.qpid.client.AMQSession
 
createDurableSubscriber(Topic, String, String, boolean) - Method in class org.apache.qpid.client.AMQSession
 
createDurableSubscriber(Topic, String) - Method in class org.apache.qpid.client.AMQTopicSessionAdaptor
 
createDurableSubscriber(Topic, String, String, boolean) - Method in class org.apache.qpid.client.AMQTopicSessionAdaptor
 
createDurableTopic(AMQTopic, String, AMQConnection) - Static method in class org.apache.qpid.client.AMQTopic
 
createEqual(Expression, Expression) - Static method in class org.apache.qpid.filter.ComparisonExpression
 
createExclusiveConsumer(Destination) - Method in class org.apache.qpid.client.AMQSession
 
createExclusiveConsumer(Destination, String, boolean) - Method in class org.apache.qpid.client.AMQSession
 
createFactory(String) - Method in class org.apache.qpid.jndi.PropertiesFileInitialContextFactory
Factory method to create new Connection Factory instances
createFloat(String) - Static method in class org.apache.qpid.filter.ConstantExpression
 
createFromDecimal(String) - Static method in class org.apache.qpid.filter.ConstantExpression
 
createFromHex(String) - Static method in class org.apache.qpid.filter.ConstantExpression
 
createFromOctal(String) - Static method in class org.apache.qpid.filter.ConstantExpression
 
createGreaterThan(Expression, Expression) - Static method in class org.apache.qpid.filter.ComparisonExpression
 
createGreaterThanEqual(Expression, Expression) - Static method in class org.apache.qpid.filter.ComparisonExpression
 
createHeaderExchange(Object) - Method in class org.apache.qpid.jndi.PropertiesFileInitialContextFactory
Factory method to create new HeaderExcahnge instances
createInExpression(PropertyExpression, List, boolean) - Static method in class org.apache.qpid.filter.UnaryExpression
 
createInFilter(Expression, List) - Static method in class org.apache.qpid.filter.ComparisonExpression
 
createIoTransportSession(BrokerDetails) - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
Called when we want to create a new IoTransport session
createIsNotNull(Expression) - Static method in class org.apache.qpid.filter.ComparisonExpression
 
createIsNull(Expression) - Static method in class org.apache.qpid.filter.ComparisonExpression
 
createJMSMessageFromUnprocessedMessage(AMQMessageDelegateFactory, U) - Method in class org.apache.qpid.client.BasicMessageConsumer
 
createJMSMessageFromUnprocessedMessage(AMQMessageDelegateFactory, UnprocessedMessage_0_10) - Method in class org.apache.qpid.client.BasicMessageConsumer_0_10
 
createJMSMessageFromUnprocessedMessage(AMQMessageDelegateFactory, UnprocessedMessage_0_8) - Method in class org.apache.qpid.client.BasicMessageConsumer_0_8
 
createLessThan(Expression, Expression) - Static method in class org.apache.qpid.filter.ComparisonExpression
 
createLessThanEqual(Expression, Expression) - Static method in class org.apache.qpid.filter.ComparisonExpression
 
createLike(Expression, String, String) - Static method in class org.apache.qpid.filter.ComparisonExpression
 
createMapMessage() - Method in class org.apache.qpid.client.AMQQueueSessionAdaptor
 
createMapMessage() - Method in class org.apache.qpid.client.AMQSession
 
createMapMessage() - Method in class org.apache.qpid.client.AMQTopicSessionAdaptor
 
createMessage() - Method in class org.apache.qpid.client.AMQQueueSessionAdaptor
 
createMessage() - Method in class org.apache.qpid.client.AMQSession
 
createMessage() - Method in class org.apache.qpid.client.AMQTopicSessionAdaptor
 
createMessage(AMQMessageDelegate, ByteBuffer) - Method in class org.apache.qpid.client.message.AbstractJMSMessageFactory
 
createMessage(long, boolean, ContentHeaderBody, AMQShortString, AMQShortString, List) - Method in class org.apache.qpid.client.message.AbstractJMSMessageFactory
 
createMessage(long, boolean, MessageProperties, DeliveryProperties, ByteBuffer) - Method in class org.apache.qpid.client.message.AbstractJMSMessageFactory
 
createMessage(AMQMessageDelegate, ByteBuffer) - Method in class org.apache.qpid.client.message.AMQPEncodedMapMessageFactory
 
createMessage(AMQMessageDelegateFactory) - Method in class org.apache.qpid.client.message.AMQPEncodedMapMessageFactory
 
createMessage(AMQMessageDelegate, ByteBuffer) - Method in class org.apache.qpid.client.message.JMSBytesMessageFactory
 
createMessage(AMQMessageDelegateFactory) - Method in class org.apache.qpid.client.message.JMSBytesMessageFactory
 
createMessage(AMQMessageDelegateFactory) - Method in class org.apache.qpid.client.message.JMSMapMessageFactory
 
createMessage(AMQMessageDelegate, ByteBuffer) - Method in class org.apache.qpid.client.message.JMSMapMessageFactory
 
createMessage(AMQMessageDelegate, ByteBuffer) - Method in class org.apache.qpid.client.message.JMSObjectMessageFactory
 
createMessage(AMQMessageDelegateFactory) - Method in class org.apache.qpid.client.message.JMSObjectMessageFactory
 
createMessage(AMQMessageDelegate, ByteBuffer) - Method in class org.apache.qpid.client.message.JMSStreamMessageFactory
 
createMessage(AMQMessageDelegateFactory) - Method in class org.apache.qpid.client.message.JMSStreamMessageFactory
 
createMessage(AMQMessageDelegateFactory) - Method in class org.apache.qpid.client.message.JMSTextMessageFactory
 
createMessage(AMQMessageDelegate, ByteBuffer) - Method in class org.apache.qpid.client.message.JMSTextMessageFactory
 
createMessage(long, boolean, ContentHeaderBody, AMQShortString, AMQShortString, List) - Method in interface org.apache.qpid.client.message.MessageFactory
 
createMessage(long, boolean, MessageProperties, DeliveryProperties, ByteBuffer) - Method in interface org.apache.qpid.client.message.MessageFactory
 
createMessage(AMQMessageDelegateFactory) - Method in interface org.apache.qpid.client.message.MessageFactory
 
createMessage(long, boolean, AMQShortString, AMQShortString, ContentHeaderBody, List) - Method in class org.apache.qpid.client.message.MessageFactoryRegistry
Create a message.
createMessage(MessageTransfer) - Method in class org.apache.qpid.client.message.MessageFactoryRegistry
 
createMessage(AMQMessageDelegateFactory, String) - Method in class org.apache.qpid.client.message.MessageFactoryRegistry
 
createMessageConsumer(AMQDestination, int, int, boolean, boolean, String, FieldTable, boolean, boolean) - Method in class org.apache.qpid.client.AMQSession
 
createMessageConsumer(AMQDestination, int, int, boolean, boolean, String, FieldTable, boolean, boolean) - Method in class org.apache.qpid.client.AMQSession_0_10
Create an 0_10 message consumer
createMessageConsumer(AMQDestination, int, int, boolean, boolean, String, FieldTable, boolean, boolean) - Method in class org.apache.qpid.client.AMQSession_0_8
 
createMessageProducer(Destination, boolean, boolean, boolean, long) - Method in class org.apache.qpid.client.AMQSession
 
createMessageProducer(Destination, boolean, boolean, boolean, long) - Method in class org.apache.qpid.client.AMQSession_0_10
Create an 0_10 message producer
createMessageProducer(Destination, boolean, boolean, boolean, long) - Method in class org.apache.qpid.client.AMQSession_0_8
 
createMinus(Expression, Expression) - Static method in class org.apache.qpid.filter.ArithmeticExpression
 
createMod(Expression, Expression) - Static method in class org.apache.qpid.filter.ArithmeticExpression
 
createMultiply(Expression, Expression) - Static method in class org.apache.qpid.filter.ArithmeticExpression
 
createNegate(Expression) - Static method in class org.apache.qpid.filter.UnaryExpression
 
createNOT(BooleanExpression) - Static method in class org.apache.qpid.filter.UnaryExpression
 
createNotBetween(Expression, Expression, Expression) - Static method in class org.apache.qpid.filter.ComparisonExpression
 
createNotEqual(Expression, Expression) - Static method in class org.apache.qpid.filter.ComparisonExpression
 
createNotInFilter(Expression, List) - Static method in class org.apache.qpid.filter.ComparisonExpression
 
createNotLike(Expression, String, String) - Static method in class org.apache.qpid.filter.ComparisonExpression
 
createObjectMessage() - Method in class org.apache.qpid.client.AMQQueueSessionAdaptor
 
createObjectMessage(Serializable) - Method in class org.apache.qpid.client.AMQQueueSessionAdaptor
 
createObjectMessage() - Method in class org.apache.qpid.client.AMQSession
 
createObjectMessage(Serializable) - Method in class org.apache.qpid.client.AMQSession
 
createObjectMessage() - Method in class org.apache.qpid.client.AMQTopicSessionAdaptor
 
createObjectMessage(Serializable) - Method in class org.apache.qpid.client.AMQTopicSessionAdaptor
 
createOR(BooleanExpression, BooleanExpression) - Static method in class org.apache.qpid.filter.LogicExpression
 
createPlus(Expression, Expression) - Static method in class org.apache.qpid.filter.ArithmeticExpression
 
createProducer(Destination) - Method in class org.apache.qpid.client.AMQQueueSessionAdaptor
 
createProducer(Destination) - Method in class org.apache.qpid.client.AMQSession
 
createProducer(Destination, boolean) - Method in class org.apache.qpid.client.AMQSession
 
createProducer(Destination, boolean, boolean) - Method in class org.apache.qpid.client.AMQSession
 
createProducer(Destination, boolean, boolean, boolean) - Method in class org.apache.qpid.client.AMQSession
 
createProducer(Destination) - Method in class org.apache.qpid.client.AMQTopicSessionAdaptor
 
createProducer(Destination, boolean, boolean) - Method in interface org.apache.qpid.jms.Session
Create a producer
createProducer(Destination, boolean) - Method in interface org.apache.qpid.jms.Session
Create a producer
createPublisher(Topic) - Method in class org.apache.qpid.client.AMQSession
 
createPublisher(Topic) - Method in class org.apache.qpid.client.AMQTopicSessionAdaptor
 
createQueue(String) - Method in class org.apache.qpid.client.AMQQueueSessionAdaptor
 
createQueue(String) - Method in class org.apache.qpid.client.AMQSession
 
createQueue(AMQShortString, boolean, boolean, boolean) - Method in class org.apache.qpid.client.AMQSession
Declares the named queue.
createQueue(AMQShortString, boolean, boolean, boolean, Map<String, Object>) - Method in class org.apache.qpid.client.AMQSession
Declares the named queue.
createQueue(String) - Method in class org.apache.qpid.client.AMQTopicSessionAdaptor
 
createQueue(Object) - Method in class org.apache.qpid.jndi.PropertiesFileInitialContextFactory
Factory method to create new Queue instances
createQueueConnection() - Method in class org.apache.qpid.client.AMQConnectionFactory
 
createQueueConnection(String, String) - Method in class org.apache.qpid.client.AMQConnectionFactory
 
createQueueReceiver(Destination) - Method in class org.apache.qpid.client.AMQSession
Creates a QueueReceiver
createQueueReceiver(Destination, String) - Method in class org.apache.qpid.client.AMQSession
Creates a QueueReceiver using a message selector
createQueues(Map, Hashtable) - Method in class org.apache.qpid.jndi.PropertiesFileInitialContextFactory
 
createQueueSession(boolean, int) - Method in class org.apache.qpid.client.AMQConnection
Returns an AMQQueueSessionAdaptor which wraps an AMQSession and throws IllegalStateExceptions where specified in the JMS spec
createReceiver(Queue) - Method in class org.apache.qpid.client.AMQQueueSessionAdaptor
 
createReceiver(Queue, String) - Method in class org.apache.qpid.client.AMQQueueSessionAdaptor
 
createReceiver(Queue) - Method in class org.apache.qpid.client.AMQSession
Creates a QueueReceiver wrapping a MessageConsumer
createReceiver(Queue, String) - Method in class org.apache.qpid.client.AMQSession
Creates a QueueReceiver wrapping a MessageConsumer using a message selector
createSaslClient(String[], String, String, String, Map, CallbackHandler) - Method in class org.apache.qpid.client.security.amqplain.AmqPlainSaslClientFactory
 
createSaslClient(String[], String, String, String, Map<String, ?>, CallbackHandler) - Method in class org.apache.qpid.client.security.crammd5hashed.CRAMMD5HashedSaslClientFactory
 
createSender(Queue) - Method in class org.apache.qpid.client.AMQQueueSessionAdaptor
 
createSender(Queue) - Method in class org.apache.qpid.client.AMQSession
 
createSession(boolean, int) - Method in class org.apache.qpid.client.AMQConnection
 
createSession(boolean, int, int) - Method in class org.apache.qpid.client.AMQConnection
 
createSession(boolean, int, int, int) - Method in class org.apache.qpid.client.AMQConnection
 
createSession(boolean, int, int, int) - Method in interface org.apache.qpid.client.AMQConnectionDelegate
 
createSession(boolean, int, int, int) - Method in class org.apache.qpid.client.AMQConnectionDelegate_0_10
create a Session and start it if required.
createSession(boolean, int, int) - Method in class org.apache.qpid.client.AMQConnectionDelegate_8_0
 
createSession(boolean, int, int, int) - Method in class org.apache.qpid.client.AMQConnectionDelegate_8_0
 
createSession() - Method in class org.apache.qpid.client.XASessionImpl
Create a qpid session.
createSession(boolean, int, int) - Method in interface org.apache.qpid.jms.Connection
Create a session specifying the prefetch limit of messages.
createSession(boolean, int, int, int) - Method in interface org.apache.qpid.jms.Connection
Create a session specifying the prefetch limit of messages.
createStreamMessage() - Method in class org.apache.qpid.client.AMQQueueSessionAdaptor
 
createStreamMessage() - Method in class org.apache.qpid.client.AMQSession
 
createStreamMessage() - Method in class org.apache.qpid.client.AMQTopicSessionAdaptor
 
createSubcontext(Name) - Method in class org.apache.qpid.jndi.ReadOnlyContext
 
createSubcontext(String) - Method in class org.apache.qpid.jndi.ReadOnlyContext
 
createSubcontext(Name) - Method in class org.apache.qpid.naming.ReadOnlyContext
 
createSubcontext(String) - Method in class org.apache.qpid.naming.ReadOnlyContext
 
createSubscriber(Topic) - Method in class org.apache.qpid.client.AMQSession
Creates a non-durable subscriber
createSubscriber(Topic, String, boolean) - Method in class org.apache.qpid.client.AMQSession
Creates a non-durable subscriber with a message selector
createSubscriber(Topic) - Method in class org.apache.qpid.client.AMQTopicSessionAdaptor
 
createSubscriber(Topic, String, boolean) - Method in class org.apache.qpid.client.AMQTopicSessionAdaptor
 
createTemporaryQueue() - Method in class org.apache.qpid.client.AMQQueueSessionAdaptor
 
createTemporaryQueue() - Method in class org.apache.qpid.client.AMQSession
 
createTemporaryQueue() - Method in class org.apache.qpid.client.AMQTopicSessionAdaptor
 
createTemporaryTopic() - Method in class org.apache.qpid.client.AMQQueueSessionAdaptor
 
createTemporaryTopic() - Method in class org.apache.qpid.client.AMQSession
 
createTemporaryTopic() - Method in class org.apache.qpid.client.AMQTopicSessionAdaptor
 
createTextMessage() - Method in class org.apache.qpid.client.AMQQueueSessionAdaptor
 
createTextMessage(String) - Method in class org.apache.qpid.client.AMQQueueSessionAdaptor
 
createTextMessage() - Method in class org.apache.qpid.client.AMQSession
 
createTextMessage(String) - Method in class org.apache.qpid.client.AMQSession
 
createTextMessage() - Method in class org.apache.qpid.client.AMQTopicSessionAdaptor
 
createTextMessage(String) - Method in class org.apache.qpid.client.AMQTopicSessionAdaptor
 
createTopic(String) - Method in class org.apache.qpid.client.AMQQueueSessionAdaptor
 
createTopic(String) - Method in class org.apache.qpid.client.AMQSession
 
createTopic(String) - Method in class org.apache.qpid.client.AMQTopicSessionAdaptor
 
createTopic(Object) - Method in class org.apache.qpid.jndi.PropertiesFileInitialContextFactory
Factory method to create new Topic instances
createTopicConnection() - Method in class org.apache.qpid.client.AMQConnectionFactory
 
createTopicConnection(String, String) - Method in class org.apache.qpid.client.AMQConnectionFactory
 
createTopics(Map, Hashtable) - Method in class org.apache.qpid.jndi.PropertiesFileInitialContextFactory
 
createTopicSession(boolean, int) - Method in class org.apache.qpid.client.AMQConnection
Returns an AMQTopicSessionAdapter which wraps an AMQSession and throws IllegalStateExceptions where specified in the JMS spec
createVMBroker(int) - Static method in class org.apache.qpid.client.transport.TransportConnection
 
createWaiter(Set<AMQState>) - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
 
createWaiter(Set<AMQState>) - Method in class org.apache.qpid.client.state.AMQStateManager
Create and add a new waiter to the notifcation list.
createXAConnection() - Method in class org.apache.qpid.client.AMQConnectionFactory
Creates a XAConnection with the default user identity.
createXAConnection(String, String) - Method in class org.apache.qpid.client.AMQConnectionFactory
Creates a XAConnection with the specified user identity.
createXAQueueConnection() - Method in class org.apache.qpid.client.AMQConnectionFactory
Creates a XAQueueConnection with the default user identity.
createXAQueueConnection(String, String) - Method in class org.apache.qpid.client.AMQConnectionFactory
Creates a XAQueueConnection with the specified user identity.
createXAQueueSession() - Method in class org.apache.qpid.client.XAConnectionImpl
Creates an XAQueueSession.
createXASession() - Method in interface org.apache.qpid.client.AMQConnectionDelegate
Create an XASession with default prefetch values of: High = MaxPrefetch Low = MaxPrefetch / 2
createXASession(int, int) - Method in interface org.apache.qpid.client.AMQConnectionDelegate
 
createXASession() - Method in class org.apache.qpid.client.AMQConnectionDelegate_0_10
Create an XASession with default prefetch values of: High = MaxPrefetch Low = MaxPrefetch / 2
createXASession(int, int) - Method in class org.apache.qpid.client.AMQConnectionDelegate_0_10
create an XA Session and start it if required.
createXASession(int, int) - Method in class org.apache.qpid.client.AMQConnectionDelegate_8_0
 
createXASession() - Method in class org.apache.qpid.client.AMQConnectionDelegate_8_0
Create an XASession with default prefetch values of: High = MaxPrefetch Low = MaxPrefetch / 2
createXASession() - Method in class org.apache.qpid.client.XAConnectionImpl
Creates an XASession.
createXATopicConnection() - Method in class org.apache.qpid.client.AMQConnectionFactory
Creates a XATopicConnection with the default user identity.
createXATopicConnection(String, String) - Method in class org.apache.qpid.client.AMQConnectionFactory
Creates a XATopicConnection with the specified user identity.
createXATopicSession() - Method in class org.apache.qpid.client.XAConnectionImpl
Creates an XAQueueSession.
curChar - Variable in class org.apache.qpid.filter.selector.SelectorParserTokenManager
 
curLexState - Variable in class org.apache.qpid.filter.selector.SelectorParserTokenManager
 
currentToken - Variable in exception org.apache.qpid.filter.selector.ParseException
This is the last token that has been consumed successfully.
CustomJMSXProperty - Enum in org.apache.qpid.client
 

D

debugIdentity() - Method in class org.apache.qpid.client.BasicMessageConsumer
 
debugStream - Variable in class org.apache.qpid.filter.selector.SelectorParserTokenManager
Debug output.
DECIMAL_LITERAL - Static variable in interface org.apache.qpid.filter.selector.SelectorParserConstants
RegularExpression Id.
DECLARE_EXCHANGES - Variable in class org.apache.qpid.client.AMQSession
 
DECLARE_QUEUES - Variable in class org.apache.qpid.client.AMQSession
 
declareAndBind(AMQDestination) - Method in class org.apache.qpid.client.AMQSession
 
declareDestination(AMQDestination) - Method in class org.apache.qpid.client.BasicMessageProducer
 
declareDestination(AMQDestination) - Method in class org.apache.qpid.client.BasicMessageProducer_0_10
 
declareDestination(AMQDestination) - Method in class org.apache.qpid.client.BasicMessageProducer_0_8
 
declareExchange(AMQShortString, AMQShortString, boolean) - Method in class org.apache.qpid.client.AMQSession
 
declareQueue(AMQDestination, AMQProtocolHandler, boolean) - Method in class org.apache.qpid.client.AMQSession
Declares a queue for a JMS destination.
declareQueue(AMQDestination, AMQProtocolHandler, boolean, boolean) - Method in class org.apache.qpid.client.AMQSession
 
declareQueue(AMQDestination, AMQProtocolHandler, boolean, boolean) - Method in class org.apache.qpid.client.AMQSession_0_10
 
DEFAULT - Static variable in interface org.apache.qpid.filter.selector.SelectorParserConstants
Lexical state.
DEFAULT_CONNECT_TIMEOUT - Static variable in interface org.apache.qpid.jms.BrokerDetails
 
DEFAULT_CYCLE_RETRIES - Static variable in class org.apache.qpid.jms.failover.FailoverRoundRobinServers
The default number of times to cycle through all servers
DEFAULT_FACTORY - Static variable in interface org.apache.qpid.client.message.AMQMessageDelegateFactory
 
DEFAULT_FLOW_CONTROL_WAIT_FAILURE - Static variable in class org.apache.qpid.client.AMQSession
The period to wait while flow controlled before declaring a failure
DEFAULT_FREQUENCY - Static variable in class org.apache.qpid.client.protocol.ProtocolBufferMonitorFilter
 
DEFAULT_IMMEDIATE - Variable in class org.apache.qpid.client.AMQSession
The default value for immediate flag used by producers created by this session is false.
DEFAULT_MANDATORY - Variable in class org.apache.qpid.client.AMQSession
The default value for mandatory flag used by producers created by this session is true.
DEFAULT_PORT - Static variable in interface org.apache.qpid.jms.BrokerDetails
 
DEFAULT_RESOURCE_NAME - Static variable in class org.apache.qpid.client.security.CallbackHandlerRegistry
The default name of the callback handler properties resource.
DEFAULT_RESOURCE_NAME - Static variable in class org.apache.qpid.client.security.DynamicSaslRegistrar
The default name of the SASL properties file resource.
DEFAULT_SERVER_RETRIES - Static variable in class org.apache.qpid.jms.failover.FailoverRoundRobinServers
The default number of times to retry each server
DEFAULT_SERVER_RETRIES - Static variable in class org.apache.qpid.jms.failover.FailoverSingleServer
The default number of times to rety a conection to this server
DEFAULT_THRESHOLD - Static variable in class org.apache.qpid.client.protocol.ProtocolBufferMonitorFilter
 
DEFAULT_TRANSPORT - Static variable in interface org.apache.qpid.jms.BrokerDetails
 
DEFAULT_WAIT_ON_SEND - Variable in class org.apache.qpid.client.AMQSession
 
defaultDestSyntax - Static variable in class org.apache.qpid.client.AMQDestination
 
defaultLexState - Variable in class org.apache.qpid.filter.selector.SelectorParserTokenManager
 
DefaultMapEntry - Class in org.apache.qpid.collections.keyvalue
A restricted implementation of Map.Entry that prevents the Map.Entry contract from being broken.
DefaultMapEntry(Object, Object) - Constructor for class org.apache.qpid.collections.keyvalue.DefaultMapEntry
Constructs a new entry with the specified key and given value.
DefaultMapEntry(KeyValue) - Constructor for class org.apache.qpid.collections.keyvalue.DefaultMapEntry
Constructs a new entry from the specified KeyValue.
DefaultMapEntry(Map.Entry) - Constructor for class org.apache.qpid.collections.keyvalue.DefaultMapEntry
Constructs a new entry from the specified Map.Entry.
delete() - Method in class org.apache.qpid.client.AMQTemporaryQueue
 
delete() - Method in class org.apache.qpid.client.AMQTemporaryTopic
 
DELETE - Static variable in class org.apache.qpid.client.messaging.address.AddressHelper
 
delete() - Method in interface org.apache.qpid.client.TemporaryDestination
 
deleteQueue(AMQShortString) - Method in class org.apache.qpid.client.AMQSession
Undeclares the specified queue.
deregisterConsumer(C) - Method in class org.apache.qpid.client.AMQSession
Called by the MessageConsumer when closing, to deregister the consumer from the map from consumerTag to consumer instance.
deregisterFactory(String) - Method in class org.apache.qpid.client.message.MessageFactoryRegistry
 
deregisterProducer(long) - Method in class org.apache.qpid.client.AMQSession
 
deregisterSession(int) - Method in class org.apache.qpid.client.AMQConnection
 
destroySubcontext(Name) - Method in class org.apache.qpid.jndi.ReadOnlyContext
 
destroySubcontext(String) - Method in class org.apache.qpid.jndi.ReadOnlyContext
 
destroySubcontext(Name) - Method in class org.apache.qpid.naming.ReadOnlyContext
 
destroySubcontext(String) - Method in class org.apache.qpid.naming.ReadOnlyContext
 
destType - Variable in class org.apache.qpid.client.message.ExchangeInfo
 
disable_tracing() - Method in class org.apache.qpid.filter.selector.SelectorParser
Disable tracing.
dispatch(UnprocessedMessage) - Method in class org.apache.qpid.client.AMQSession
 
dispatch(AMQSession) - Method in interface org.apache.qpid.client.AMQSession.Dispatchable
 
dispatch(AMQSession) - Method in class org.apache.qpid.client.message.UnprocessedMessage
 
dispatchAccessRequest(AccessRequestBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchAccessRequestOk(AccessRequestOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchBasicAck(BasicAckBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchBasicCancel(BasicCancelBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchBasicCancelOk(BasicCancelOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchBasicConsume(BasicConsumeBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchBasicConsumeOk(BasicConsumeOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchBasicDeliver(BasicDeliverBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchBasicGet(BasicGetBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchBasicGetEmpty(BasicGetEmptyBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchBasicGetOk(BasicGetOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchBasicPublish(BasicPublishBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchBasicQos(BasicQosBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchBasicQosOk(BasicQosOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchBasicRecover(BasicRecoverBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchBasicRecoverOk(BasicRecoverOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_91
 
dispatchBasicRecoverOk(BasicRecoverOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_8_0
 
dispatchBasicRecoverSync(BasicRecoverSyncBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_9
 
dispatchBasicRecoverSync(BasicRecoverSyncBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_91
 
dispatchBasicRecoverSyncOk(BasicRecoverSyncOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_9
 
dispatchBasicRecoverSyncOk(BasicRecoverSyncOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_91
 
dispatchBasicReject(BasicRejectBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchBasicReturn(BasicReturnBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchChannelAlert(ChannelAlertBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_8_0
 
dispatchChannelClose(ChannelCloseBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchChannelCloseOk(ChannelCloseOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchChannelFlow(ChannelFlowBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchChannelFlowOk(ChannelFlowOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchChannelOk(ChannelOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_9
 
dispatchChannelOk(ChannelOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_91
 
dispatchChannelOpen(ChannelOpenBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchChannelOpenOk(ChannelOpenOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchChannelPing(ChannelPingBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_9
 
dispatchChannelPing(ChannelPingBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_91
 
dispatchChannelPong(ChannelPongBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_9
 
dispatchChannelPong(ChannelPongBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_91
 
dispatchChannelResume(ChannelResumeBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_9
 
dispatchChannelResume(ChannelResumeBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_91
 
dispatchConnectionClose(ConnectionCloseBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchConnectionCloseOk(ConnectionCloseOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchConnectionOpen(ConnectionOpenBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchConnectionOpenOk(ConnectionOpenOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchConnectionRedirect(ConnectionRedirectBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchConnectionSecure(ConnectionSecureBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchConnectionSecureOk(ConnectionSecureOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchConnectionStart(ConnectionStartBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchConnectionStartOk(ConnectionStartOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchConnectionTune(ConnectionTuneBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchConnectionTuneOk(ConnectionTuneOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchDtxSelect(DtxSelectBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchDtxSelectOk(DtxSelectOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchDtxStart(DtxStartBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchDtxStartOk(DtxStartOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
DispatcherCallback - Class in org.apache.qpid.client
 
DispatcherCallback(BasicMessageConsumer) - Constructor for class org.apache.qpid.client.DispatcherCallback
 
dispatchExchangeBound(ExchangeBoundBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchExchangeBoundOk(ExchangeBoundOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchExchangeDeclare(ExchangeDeclareBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchExchangeDeclareOk(ExchangeDeclareOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchExchangeDelete(ExchangeDeleteBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchExchangeDeleteOk(ExchangeDeleteOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchFileAck(FileAckBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchFileCancel(FileCancelBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchFileCancelOk(FileCancelOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchFileConsume(FileConsumeBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchFileConsumeOk(FileConsumeOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchFileDeliver(FileDeliverBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchFileOpen(FileOpenBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchFileOpenOk(FileOpenOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchFilePublish(FilePublishBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchFileQos(FileQosBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchFileQosOk(FileQosOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchFileReject(FileRejectBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchFileReturn(FileReturnBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchFileStage(FileStageBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchMessageAppend(MessageAppendBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_9
 
dispatchMessageAppend(MessageAppendBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_91
 
dispatchMessageCancel(MessageCancelBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_9
 
dispatchMessageCancel(MessageCancelBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_91
 
dispatchMessageCheckpoint(MessageCheckpointBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_9
 
dispatchMessageCheckpoint(MessageCheckpointBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_91
 
dispatchMessageClose(MessageCloseBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_9
 
dispatchMessageClose(MessageCloseBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_91
 
dispatchMessageConsume(MessageConsumeBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_9
 
dispatchMessageConsume(MessageConsumeBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_91
 
dispatchMessageEmpty(MessageEmptyBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_9
 
dispatchMessageEmpty(MessageEmptyBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_91
 
dispatchMessageGet(MessageGetBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_9
 
dispatchMessageGet(MessageGetBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_91
 
dispatchMessageOffset(MessageOffsetBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_9
 
dispatchMessageOffset(MessageOffsetBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_91
 
dispatchMessageOk(MessageOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_9
 
dispatchMessageOk(MessageOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_91
 
dispatchMessageOpen(MessageOpenBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_9
 
dispatchMessageOpen(MessageOpenBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_91
 
dispatchMessageQos(MessageQosBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_9
 
dispatchMessageQos(MessageQosBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_91
 
dispatchMessageRecover(MessageRecoverBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_9
 
dispatchMessageRecover(MessageRecoverBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_91
 
dispatchMessageReject(MessageRejectBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_9
 
dispatchMessageReject(MessageRejectBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_91
 
dispatchMessageResume(MessageResumeBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_9
 
dispatchMessageResume(MessageResumeBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_91
 
dispatchMessageTransfer(MessageTransferBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_9
 
dispatchMessageTransfer(MessageTransferBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_91
 
dispatchQueueBind(QueueBindBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchQueueBindOk(QueueBindOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchQueueDeclare(QueueDeclareBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchQueueDeclareOk(QueueDeclareOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchQueueDelete(QueueDeleteBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchQueueDeleteOk(QueueDeleteOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchQueuePurge(QueuePurgeBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchQueuePurgeOk(QueuePurgeOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchQueueUnbind(QueueUnbindBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_9
 
dispatchQueueUnbind(QueueUnbindBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_91
 
dispatchQueueUnbindOk(QueueUnbindOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_9
 
dispatchQueueUnbindOk(QueueUnbindOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_0_91
 
dispatchStreamCancel(StreamCancelBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchStreamCancelOk(StreamCancelOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchStreamConsume(StreamConsumeBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchStreamConsumeOk(StreamConsumeOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchStreamDeliver(StreamDeliverBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchStreamPublish(StreamPublishBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchStreamQos(StreamQosBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchStreamQosOk(StreamQosOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchStreamReturn(StreamReturnBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchTestContent(TestContentBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_8_0
 
dispatchTestContentOk(TestContentOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_8_0
 
dispatchTestInteger(TestIntegerBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_8_0
 
dispatchTestIntegerOk(TestIntegerOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_8_0
 
dispatchTestString(TestStringBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_8_0
 
dispatchTestStringOk(TestStringOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_8_0
 
dispatchTestTable(TestTableBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_8_0
 
dispatchTestTableOk(TestTableOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl_8_0
 
dispatchTunnelRequest(TunnelRequestBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchTxCommit(TxCommitBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchTxCommitOk(TxCommitOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchTxRollback(TxRollbackBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchTxRollbackOk(TxRollbackOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchTxSelect(TxSelectBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispatchTxSelectOk(TxSelectOkBody, int) - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
dispose() - Method in class org.apache.qpid.client.security.amqplain.AmqPlainSaslClient
 
divide(Number, Number) - Method in class org.apache.qpid.filter.ArithmeticExpression
 
Done() - Method in class org.apache.qpid.filter.selector.SimpleCharStream
Reset buffer when finished.
DOUBLE - Static variable in class org.apache.qpid.filter.ArithmeticExpression
 
DOUBLE_TYPE - Static variable in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
drainReceiverQueueAndRetrieveDeliveryTags() - Method in class org.apache.qpid.client.BasicMessageConsumer
 
DURABLE - Static variable in class org.apache.qpid.client.messaging.address.AddressHelper
 
DynamicSaslRegistrar - Class in org.apache.qpid.client.security
DynamicSaslRegistrar provides a collection of helper methods for reading a configuration file that contains a mapping from SASL mechanism names to implementing client factory class names and registering a security provider with the Java runtime system, that uses the configured client factory implementations.
DynamicSaslRegistrar() - Constructor for class org.apache.qpid.client.security.DynamicSaslRegistrar
 

E

enable_tracing() - Method in class org.apache.qpid.filter.selector.SelectorParser
Enable tracing.
encodeString(String) - Static method in class org.apache.qpid.filter.ConstantExpression
Encodes the value of string so that it looks like it would look like when it was provided in a selector.
end(Xid, int) - Method in class org.apache.qpid.client.XAResourceImpl
Ends the work performed on behalf of a transaction branch.
endColumn - Variable in class org.apache.qpid.filter.selector.Token
The column number of the last character of this Token.
endLine - Variable in class org.apache.qpid.filter.selector.Token
The line number of the last character of this Token.
entrySet() - Method in class org.apache.qpid.collections.ReferenceMap
Deprecated. Returns a set view of this map's entries.
environment - Variable in class org.apache.qpid.jndi.ReadOnlyContext
 
environment - Variable in class org.apache.qpid.naming.ReadOnlyContext
 
EOF - Static variable in interface org.apache.qpid.filter.selector.SelectorParserConstants
End of File.
eol - Variable in exception org.apache.qpid.filter.selector.ParseException
The end of line string for this machine.
equalityExpression() - Method in class org.apache.qpid.filter.selector.SelectorParser
 
equals(Object) - Method in class org.apache.qpid.client.AMQBrokerDetails
 
equals(Object) - Method in class org.apache.qpid.client.AMQDestination
 
equals(Object) - Method in class org.apache.qpid.client.AMQTopic
 
equals(Object) - Method in class org.apache.qpid.collections.keyvalue.AbstractMapEntry
Compares this Map.Entry with another Map.Entry.
equals(Object) - Method in class org.apache.qpid.filter.BinaryExpression
TODO: more efficient hashCode()
equals(Object) - Method in class org.apache.qpid.filter.ConstantExpression
TODO: more efficient hashCode()
equals(Object) - Method in class org.apache.qpid.filter.PropertyExpression
 
equals(Object) - Method in class org.apache.qpid.filter.UnaryExpression
TODO: more efficient hashCode()
equals(Object) - Method in interface org.apache.qpid.jms.BrokerDetails
 
error(Exception) - Method in class org.apache.qpid.client.state.AMQStateManager
Propogate error to waiters
error(Exception) - Method in class org.apache.qpid.client.util.BlockingWaiter
This is a callback, called when an error has occured that should interupt any waiter.
errorCode - Variable in error org.apache.qpid.filter.selector.TokenMgrError
Indicates the reason why the exception is thrown.
ESCAPE - Static variable in interface org.apache.qpid.filter.selector.SelectorParserConstants
RegularExpression Id.
evaluate(AbstractJMSMessage) - Method in class org.apache.qpid.filter.ArithmeticExpression
 
evaluate(Object, Object) - Method in class org.apache.qpid.filter.ArithmeticExpression
 
evaluate(AbstractJMSMessage) - Method in class org.apache.qpid.filter.ComparisonExpression
 
evaluate(AbstractJMSMessage) - Method in class org.apache.qpid.filter.ComparisonExpression.LikeExpression
org.apache.activemq.filter.Expression#evaluate(MessageEvaluationContext)
evaluate(AbstractJMSMessage) - Method in class org.apache.qpid.filter.ConstantExpression
 
evaluate(AbstractJMSMessage) - Method in interface org.apache.qpid.filter.Expression
 
evaluate(AbstractJMSMessage) - Method in class org.apache.qpid.filter.LogicExpression
 
evaluate(AbstractJMSMessage) - Method in class org.apache.qpid.filter.PropertyExpression
 
evaluateChallenge(byte[]) - Method in class org.apache.qpid.client.security.amqplain.AmqPlainSaslClient
 
exception(Connection, ConnectionException) - Method in class org.apache.qpid.client.AMQConnectionDelegate_0_10
 
exception(Session, SessionException) - Method in class org.apache.qpid.client.AMQSession_0_10
 
exception(Throwable) - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
Invoked when any exception is thrown by the NetworkDriver
exceptionReceived(Throwable) - Method in class org.apache.qpid.client.AMQConnection
Invoked by the AMQProtocolSession when a protocol session exception has occurred.
exchange - Variable in class org.apache.qpid.client.AMQDestination.Binding
 
EXCHANGE - Static variable in class org.apache.qpid.client.messaging.address.AddressHelper
 
ExchangeBoundOkMethodHandler - Class in org.apache.qpid.client.handler
 
ExchangeInfo - Class in org.apache.qpid.client.message
 
ExchangeInfo(String, String, int) - Constructor for class org.apache.qpid.client.message.ExchangeInfo
 
exchangeMapContains(String) - Static method in class org.apache.qpid.client.message.AbstractAMQMessageDelegate
Accessor method to allow lookups of the given exchange name.
exchangeName - Variable in class org.apache.qpid.client.message.ExchangeInfo
 
exchangeType - Variable in class org.apache.qpid.client.message.ExchangeInfo
 
EXCLUSIVE - Static variable in class org.apache.qpid.client.messaging.address.AddressHelper
 
execute() - Method in class org.apache.qpid.client.failover.FailoverNoopSupport
Delegates to another continuation which is to be provided with fail-over handling.
execute() - Method in interface org.apache.qpid.client.failover.FailoverProtectedOperation
Performs the continuations work.
execute() - Method in class org.apache.qpid.client.failover.FailoverRetrySupport
Delays a continuation until the "not failing over" condition is met on the specified connection.
execute() - Method in interface org.apache.qpid.client.failover.FailoverSupport
Delegates to another continuation which is to be provided with fail-over handling.
executeRetrySupport(FailoverProtectedOperation<T, E>) - Method in class org.apache.qpid.client.AMQConnection
 
executeRetrySupport(FailoverProtectedOperation<T, E>) - Method in interface org.apache.qpid.client.AMQConnectionDelegate
 
executeRetrySupport(FailoverProtectedOperation<T, E>) - Method in class org.apache.qpid.client.AMQConnectionDelegate_0_10
 
executeRetrySupport(FailoverProtectedOperation<T, E>) - Method in class org.apache.qpid.client.AMQConnectionDelegate_8_0
 
ExistingSocketConnector - Class in org.apache.mina.transport.socket.nio
IoConnector for socket transport (TCP/IP).
ExistingSocketConnector() - Constructor for class org.apache.mina.transport.socket.nio.ExistingSocketConnector
Create a connector with a single processing thread using a NewThreadExecutor
ExistingSocketConnector(int, Executor) - Constructor for class org.apache.mina.transport.socket.nio.ExistingSocketConnector
Create a connector with the desired number of processing threads
ExpandBuff(boolean) - Method in class org.apache.qpid.filter.selector.SimpleCharStream
 
expectedTokenSequences - Variable in exception org.apache.qpid.filter.selector.ParseException
Each entry in this array is an array of integers.
EXPONENT - Static variable in interface org.apache.qpid.filter.selector.SelectorParserConstants
RegularExpression Id.
Expression - Interface in org.apache.qpid.filter
Represents an expression

F

FACTORY_0_10 - Static variable in interface org.apache.qpid.client.message.AMQMessageDelegateFactory
 
FACTORY_0_8 - Static variable in interface org.apache.qpid.client.message.AMQMessageDelegateFactory
 
FAILED - Static variable in class org.apache.qpid.client.failover.FailoverState
Failover has been attempted and failed.
failedOverPost() - Method in class org.apache.qpid.client.BasicMessageConsumer
 
failedOverPost() - Method in class org.apache.qpid.client.BasicMessageConsumer_0_10
 
failedOverPre() - Method in class org.apache.qpid.client.BasicMessageConsumer
to be called when a failover has occured
failover(String, int) - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
 
failover(String, int) - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
 
FAILOVER_EXCHANGE - Static variable in interface org.apache.qpid.jms.failover.FailoverMethod
 
failoverAllowed() - Method in class org.apache.qpid.client.AMQConnection
 
failoverAllowed() - Method in class org.apache.qpid.jms.failover.FailoverExchangeMethod
 
failoverAllowed() - Method in interface org.apache.qpid.jms.failover.FailoverMethod
Check if failover is possible for this method
failoverAllowed() - Method in class org.apache.qpid.jms.failover.FailoverRoundRobinServers
 
failoverAllowed() - Method in class org.apache.qpid.jms.failover.FailoverSingleServer
 
failoverAllowed() - Method in class org.apache.qpid.jms.FailoverPolicy
 
failoverComplete() - Method in interface org.apache.qpid.jms.ConnectionListener
Called once failover has completed successfully.
FailoverException - Exception in org.apache.qpid.client.failover
FailoverException is used to indicate that a synchronous request has failed to receive the reply that it is waiting for because the fail-over process has been started whilst it was waiting for its reply.
FailoverException(String) - Constructor for exception org.apache.qpid.client.failover.FailoverException
 
FailoverExchangeMethod - Class in org.apache.qpid.jms.failover
When using the Failover exchange a single broker is supplied in the URL.
FailoverExchangeMethod(ConnectionURL, AMQConnection) - Constructor for class org.apache.qpid.jms.failover.FailoverExchangeMethod
 
FailoverHandler - Class in org.apache.qpid.client.failover
FailoverHandler is a continuation that performs the failover procedure on a protocol session.
FailoverHandler(AMQProtocolHandler) - Constructor for class org.apache.qpid.client.failover.FailoverHandler
Creates a failover handler on a protocol session, for a particular MINA session (network connection).
failoverInProgress() - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
 
FailoverMethod - Interface in org.apache.qpid.jms.failover
 
FailoverNoopSupport<T,E extends Exception> - Class in org.apache.qpid.client.failover
FailoverNoopSupport is a FailoverSupport implementation that does not really provide any failover support at all.
FailoverNoopSupport(FailoverProtectedOperation<T, E>, AMQConnection) - Constructor for class org.apache.qpid.client.failover.FailoverNoopSupport
Creates an automatic retrying fail-over handler for the specified operation.
FailoverPolicy - Class in org.apache.qpid.jms
 
FailoverPolicy(ConnectionURL, AMQConnection) - Constructor for class org.apache.qpid.jms.FailoverPolicy
 
FailoverPolicy(FailoverMethod) - Constructor for class org.apache.qpid.jms.FailoverPolicy
 
FailoverPolicy(FailoverMethod, int) - Constructor for class org.apache.qpid.jms.FailoverPolicy
 
failoverPrep() - Method in class org.apache.qpid.client.AMQConnection
 
failoverPrep() - Method in interface org.apache.qpid.client.AMQConnectionDelegate
 
failoverPrep() - Method in class org.apache.qpid.client.AMQConnectionDelegate_0_10
 
failoverPrep() - Method in class org.apache.qpid.client.AMQConnectionDelegate_8_0
 
failoverPrep() - Method in class org.apache.qpid.client.AMQSession
 
failoverPrep() - Method in class org.apache.qpid.client.AMQSession_0_10
 
FailoverProtectedOperation<T,E extends Exception> - Interface in org.apache.qpid.client.failover
FailoverProtectedOperation is a continuation for an operation that may throw a FailoverException because it has been interrupted by the fail-over process.
FailoverRetrySupport<T,E extends Exception> - Class in org.apache.qpid.client.failover
FailoverRetrySupport is a continuation that wraps another continuation, delaying its execution until it is notified that a blocking condition has been met, and executing the continuation within a mutex.
FailoverRetrySupport(FailoverProtectedOperation<T, E>, AMQConnection) - Constructor for class org.apache.qpid.client.failover.FailoverRetrySupport
Creates an automatic retrying fail-over handler for the specified operation.
FailoverRoundRobinServers - Class in org.apache.qpid.jms.failover
 
FailoverRoundRobinServers(ConnectionURL) - Constructor for class org.apache.qpid.jms.failover.FailoverRoundRobinServers
 
FailoverSingleServer - Class in org.apache.qpid.jms.failover
 
FailoverSingleServer(ConnectionURL) - Constructor for class org.apache.qpid.jms.failover.FailoverSingleServer
 
FailoverSingleServer(BrokerDetails) - Constructor for class org.apache.qpid.jms.failover.FailoverSingleServer
 
FailoverState - Class in org.apache.qpid.client.failover
Defines the possible states of the failover process; not started, in progress, failed.
FailoverSupport<T,E extends Exception> - Interface in org.apache.qpid.client.failover
FailoverSupport defines an interface for different types of fail-over handlers, that provide different types of behaviour for handling fail-overs during operations that can be interrupted by the fail-over process.
FALSE - Static variable in class org.apache.qpid.filter.ConstantExpression
 
FALSE - Static variable in interface org.apache.qpid.filter.selector.SelectorParserConstants
RegularExpression Id.
FieldTableSupport - Class in org.apache.qpid.client.message
 
FieldTableSupport() - Constructor for class org.apache.qpid.client.message.FieldTableSupport
 
FillBuff() - Method in class org.apache.qpid.filter.selector.SimpleCharStream
 
FILTER - Static variable in class org.apache.qpid.client.messaging.address.AddressHelper
 
fireFailoverComplete() - Method in class org.apache.qpid.client.AMQConnection
Fires a failover complete event to the registered connection listener (if any).
firePreFailover(boolean) - Method in class org.apache.qpid.client.AMQConnection
Fire the preFailover event to the registered connection listener (if any)
firePreResubscribe() - Method in class org.apache.qpid.client.AMQConnection
Fire the preResubscribe event to the registered connection listener (if any).
FLOAT_TYPE - Static variable in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
FLOATING_POINT_LITERAL - Static variable in interface org.apache.qpid.filter.selector.SelectorParserConstants
RegularExpression Id.
FLOW_CONTROL_WAIT_FAILURE - Variable in class org.apache.qpid.client.AMQSession
 
FLOW_CONTROL_WAIT_PERIOD - Variable in class org.apache.qpid.client.AMQSession
The period to wait while flow controlled before sending a log message confirming that the session is still waiting on flow control being revoked
FlowControllingBlockingQueue - Class in org.apache.qpid.client.util
A blocking queue that emits events above a user specified threshold allowing the caller to take action (e.g.
FlowControllingBlockingQueue(int, FlowControllingBlockingQueue.ThresholdListener) - Constructor for class org.apache.qpid.client.util.FlowControllingBlockingQueue
 
FlowControllingBlockingQueue(int, int, FlowControllingBlockingQueue.ThresholdListener) - Constructor for class org.apache.qpid.client.util.FlowControllingBlockingQueue
 
FlowControllingBlockingQueue.ThresholdListener - Interface in org.apache.qpid.client.util
 
flushAcknowledgments() - Method in class org.apache.qpid.client.AMQSession
 
flushAcknowledgments() - Method in class org.apache.qpid.client.AMQSession_0_10
 
flushAcknowledgments(boolean) - Method in class org.apache.qpid.client.AMQSession_0_10
 
flushAcknowledgments() - Method in class org.apache.qpid.client.AMQSession_0_8
 
forget(Xid) - Method in class org.apache.qpid.client.XAResourceImpl
Tells the resource manager to forget about a heuristically completed transaction branch.
freeze() - Method in class org.apache.qpid.jndi.ReadOnlyContext
 
freeze() - Method in class org.apache.qpid.naming.ReadOnlyContext
 

G

generateDestination(AMQShortString, AMQShortString) - Method in class org.apache.qpid.client.message.AbstractAMQMessageDelegate
Called when a Destination is requried.
generateParseException() - Method in class org.apache.qpid.filter.selector.SelectorParser
Generate ParseException.
generateQueueName() - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
 
generateQueueName() - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
 
get(int) - Method in class org.apache.qpid.client.AMQConnection.ChannelToSessionMap
 
get(int) - Method in class org.apache.qpid.client.AMQSession.IdToConsumerMap
 
get(Object) - Method in class org.apache.qpid.collections.ReferenceMap
Deprecated. Returns the value associated with the given key, if any.
getAcknowledgeMode() - Method in class org.apache.qpid.client.AMQQueueSessionAdaptor
 
getAcknowledgeMode() - Method in class org.apache.qpid.client.AMQSession
 
getAcknowledgeMode() - Method in class org.apache.qpid.client.AMQTopicSessionAdaptor
 
getAcknowledgeMode() - Method in class org.apache.qpid.client.BasicMessageConsumer
 
getActiveBrokerDetails() - Method in class org.apache.qpid.client.AMQConnection
Get the details of the currently active broker
getAddress() - Method in class org.apache.qpid.client.AMQDestination
 
getAddressName() - Method in class org.apache.qpid.client.AMQDestination
 
getAddressType() - Method in class org.apache.qpid.client.AMQDestination
 
getAllBrokerDetails() - Method in class org.apache.qpid.client.AMQConnectionURL
 
getAllBrokerDetails() - Method in class org.apache.qpid.client.url.URLParser_0_10
 
getAllBrokerDetails() - Method in interface org.apache.qpid.jms.ConnectionURL
 
getAlternateExchange() - Method in class org.apache.qpid.client.messaging.address.Node
 
getAMQConnection() - Method in class org.apache.qpid.client.AMQSession
 
getAMQConnection() - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
 
getAMQQueueName() - Method in class org.apache.qpid.client.AMQDestination
 
getAMQSession() - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
getAMQSession() - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
getAMQSession() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
getAMQSession() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
getArgs() - Method in class org.apache.qpid.client.AMQDestination.Binding
 
getArgs() - Method in class org.apache.qpid.client.messaging.address.Link.Subscription
 
getArguments() - Method in class org.apache.qpid.client.BasicMessageConsumer
 
getAssert() - Method in class org.apache.qpid.client.AMQDestination
 
getAssert() - Method in class org.apache.qpid.client.messaging.address.AddressHelper
 
getBeginColumn() - Method in class org.apache.qpid.filter.selector.SimpleCharStream
Get token beginning column number.
getBeginLine() - Method in class org.apache.qpid.filter.selector.SimpleCharStream
Get token beginning line number.
getBindingKey() - Method in class org.apache.qpid.client.AMQDestination.Binding
 
getBindingKeys() - Method in class org.apache.qpid.client.AMQDestination
 
getBindings(Map) - Method in class org.apache.qpid.client.messaging.address.AddressHelper
 
getBindings() - Method in class org.apache.qpid.client.messaging.address.Node
 
getBodies() - Method in class org.apache.qpid.client.message.UnprocessedMessage_0_8
 
getBodyLength() - Method in class org.apache.qpid.client.message.JMSBytesMessage
 
getBoolean(String) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
getBoolean(AMQShortString) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
getBoolean(String) - Method in class org.apache.qpid.client.message.JMSMapMessage
 
getBooleanProperty(String) - Method in class org.apache.qpid.client.AMQBrokerDetails
 
getBooleanProperty(String) - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
getBooleanProperty(String) - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
getBooleanProperty(String) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
getBooleanProperty(String) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
getBooleanProperty(String) - Method in interface org.apache.qpid.jms.BrokerDetails
 
getBrokerCount() - Method in class org.apache.qpid.client.AMQConnectionURL
 
getBrokerCount() - Method in interface org.apache.qpid.jms.ConnectionURL
 
getBrokerDetails(int) - Method in class org.apache.qpid.client.AMQConnectionURL
 
getBrokerDetails(int) - Method in interface org.apache.qpid.jms.ConnectionURL
 
getBrokerVersion() - Method in class org.apache.qpid.client.QpidConnectionMetaData
 
getBufferedMessages() - Method in class org.apache.qpid.client.protocol.ProtocolBufferMonitorFilter
 
getByte(String) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
getByte(String) - Method in class org.apache.qpid.client.message.JMSMapMessage
 
getByteProperty(String) - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
getByteProperty(String) - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
getByteProperty(String) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
getByteProperty(String) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
getBytes(String) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
getBytes(AMQShortString) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
getBytes(String) - Method in class org.apache.qpid.client.message.JMSMapMessage
 
getCallbackHandlerClass(String) - Method in class org.apache.qpid.client.security.CallbackHandlerRegistry
Gets the callback handler class for a given SASL mechanism name.
getCertType() - Method in class org.apache.qpid.client.SSLConfiguration
 
getChannelId() - Method in class org.apache.qpid.client.AMQSession
 
getChannelMax() - Method in class org.apache.qpid.client.ConnectionTuneParameters
 
getChar(String) - Method in class org.apache.qpid.client.message.JMSMapMessage
 
getCharacter(String) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
getClientID() - Method in class org.apache.qpid.client.AMQConnection
 
getClientID() - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
 
getClientName() - Method in class org.apache.qpid.client.AMQConnectionURL
 
getClientName() - Method in interface org.apache.qpid.jms.ConnectionURL
 
getClientVersion() - Method in class org.apache.qpid.client.QpidConnectionMetaData
 
getColumn() - Method in class org.apache.qpid.filter.selector.SimpleCharStream
Deprecated. 
getConnection() - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
 
getConnectionListener() - Method in class org.apache.qpid.client.AMQConnection
 
getConnectionListener() - Method in interface org.apache.qpid.jms.Connection
Get the connection listener that has been registered with this connection, if any
getConnectionPrefix() - Method in class org.apache.qpid.jndi.PropertiesFileInitialContextFactory
 
getConnectionTuneParameters() - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
 
getConnectionURL() - Method in class org.apache.qpid.client.AMQConnectionFactory
 
getConnectionURLString() - Method in class org.apache.qpid.client.AMQConnectionFactory
 
getConsumer() - Method in class org.apache.qpid.client.MessageConsumerPair
 
getConsumerCapacity() - Method in class org.apache.qpid.client.messaging.address.Link
 
getConsumerTag() - Method in class org.apache.qpid.client.BasicMessageConsumer
 
getConsumerTag() - Method in class org.apache.qpid.client.message.UnprocessedMessage
 
getConsumerTagString() - Method in class org.apache.qpid.client.BasicMessageConsumer_0_10
 
getContentHeader() - Method in class org.apache.qpid.client.message.UnprocessedMessage_0_8
 
getContentHeaderProperties() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
getContentLength() - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
getContentType() - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
getContentType() - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
getContentType() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
getContentType() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
getConvertedMessage() - Method in class org.apache.qpid.client.message.MessageConverter
 
getCreate() - Method in class org.apache.qpid.client.AMQDestination
 
getCreate() - Method in class org.apache.qpid.client.messaging.address.AddressHelper
 
getCurrentBrokerDetails() - Method in class org.apache.qpid.jms.failover.FailoverExchangeMethod
 
getCurrentBrokerDetails() - Method in interface org.apache.qpid.jms.failover.FailoverMethod
If there is no current BrokerDetails the null will be returned.
getCurrentBrokerDetails() - Method in class org.apache.qpid.jms.failover.FailoverRoundRobinServers
 
getCurrentBrokerDetails() - Method in class org.apache.qpid.jms.failover.FailoverSingleServer
 
getCurrentBrokerDetails() - Method in class org.apache.qpid.jms.FailoverPolicy
 
getCurrentException() - Method in class org.apache.qpid.client.AMQSession_0_10
Get the latest thrown exception.
getCurrentMethod() - Method in class org.apache.qpid.jms.FailoverPolicy
 
getCurrentState() - Method in class org.apache.qpid.client.state.AMQStateManager
 
getData() - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
getData() - Method in class org.apache.qpid.client.message.AMQPEncodedMapMessage
 
getData() - Method in class org.apache.qpid.client.message.JMSMapMessage
 
getDeclareArgs(Map) - Method in class org.apache.qpid.client.messaging.address.AddressHelper
 
getDeclareArgs() - Method in class org.apache.qpid.client.messaging.address.Node
 
getDefaultConfig() - Method in class org.apache.mina.transport.socket.nio.ExistingSocketConnector
 
getDefaultDestSyntax() - Static method in class org.apache.qpid.client.AMQDestination
 
getDefaultPassword(String) - Method in class org.apache.qpid.client.AMQConnectionFactory
 
getDefaultPrefetch() - Method in class org.apache.qpid.client.AMQSession
 
getDefaultPrefetch() - Method in interface org.apache.qpid.jms.Session
 
getDefaultPrefetchHigh() - Method in class org.apache.qpid.client.AMQSession
 
getDefaultPrefetchHigh() - Method in interface org.apache.qpid.jms.Session
 
getDefaultPrefetchLow() - Method in class org.apache.qpid.client.AMQSession
 
getDefaultPrefetchLow() - Method in interface org.apache.qpid.jms.Session
 
getDefaultQueueExchangeName() - Method in class org.apache.qpid.client.AMQConnection
 
getDefaultQueueExchangeName() - Method in class org.apache.qpid.client.AMQConnectionURL
 
getDefaultQueueExchangeName() - Method in class org.apache.qpid.client.AMQSession
 
getDefaultQueueExchangeName() - Method in interface org.apache.qpid.jms.ConnectionURL
 
getDefaultQueueExchangeName() - Method in interface org.apache.qpid.jms.Session
 
getDefaultTopicExchangeName() - Method in class org.apache.qpid.client.AMQConnection
 
getDefaultTopicExchangeName() - Method in class org.apache.qpid.client.AMQConnectionURL
 
getDefaultTopicExchangeName() - Method in class org.apache.qpid.client.AMQSession
 
getDefaultTopicExchangeName() - Method in interface org.apache.qpid.jms.ConnectionURL
 
getDefaultTopicExchangeName() - Method in interface org.apache.qpid.jms.Session
 
getDefaultUsername(String) - Method in class org.apache.qpid.client.AMQConnectionFactory
 
getDelegate() - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
getDelete() - Method in class org.apache.qpid.client.AMQDestination
 
getDelete() - Method in class org.apache.qpid.client.messaging.address.AddressHelper
 
getDeliverBody() - Method in class org.apache.qpid.client.message.UnprocessedMessage_0_8
 
getDeliveryMode() - Method in class org.apache.qpid.client.BasicMessageProducer
 
getDeliveryMode() - Method in class org.apache.qpid.client.QueueSenderAdapter
 
getDeliveryMode() - Method in class org.apache.qpid.client.TopicPublisherAdapter
 
getDeliveryProperties() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
getDeliveryProperties() - Method in class org.apache.qpid.nclient.util.ByteBufferMessage
 
getDeliveryTag() - Method in class org.apache.qpid.client.message.AbstractJMSMessage
Get the AMQ message number assigned to this message
getDeliveryTag() - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
getDeliveryTag() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
Get the AMQ message number assigned to this message
getDeliveryTag() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
Get the AMQ message number assigned to this message
getDeliveryTag() - Method in class org.apache.qpid.client.message.CloseConsumerMessage
 
getDeliveryTag() - Method in class org.apache.qpid.client.message.UnprocessedMessage
 
getDeliveryTag() - Method in class org.apache.qpid.client.message.UnprocessedMessage_0_10
 
getDeliveryTag() - Method in class org.apache.qpid.client.message.UnprocessedMessage_0_8
 
getDestination() - Method in class org.apache.qpid.client.BasicMessageConsumer
 
getDestination() - Method in class org.apache.qpid.client.BasicMessageProducer
 
getDestination() - Method in class org.apache.qpid.client.QueueSenderAdapter
 
getDestination() - Method in class org.apache.qpid.client.TopicPublisherAdapter
 
getDestinationPrefix() - Method in class org.apache.qpid.jndi.PropertiesFileInitialContextFactory
 
getDestSyntax() - Method in class org.apache.qpid.client.AMQDestination
 
getDestType(String) - Static method in class org.apache.qpid.client.AMQDestination
 
getDestType() - Method in class org.apache.qpid.client.message.ExchangeInfo
 
getDisableMessageID() - Method in class org.apache.qpid.client.BasicMessageProducer
 
getDisableMessageID() - Method in class org.apache.qpid.client.QueueSenderAdapter
 
getDisableMessageID() - Method in class org.apache.qpid.client.TopicPublisherAdapter
 
getDisableMessageTimestamp() - Method in class org.apache.qpid.client.BasicMessageProducer
 
getDisableMessageTimestamp() - Method in class org.apache.qpid.client.QueueSenderAdapter
 
getDisableMessageTimestamp() - Method in class org.apache.qpid.client.TopicPublisherAdapter
 
getDouble(String) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
getDouble(String) - Method in class org.apache.qpid.client.message.JMSMapMessage
 
getDoubleProperty(String) - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
getDoubleProperty(String) - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
getDoubleProperty(String) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
getDoubleProperty(String) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
getDurableTopicQueueName(String, AMQConnection) - Static method in class org.apache.qpid.client.AMQTopic
 
getEncodedName() - Method in class org.apache.qpid.client.AMQDestination
 
getEncoding() - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
getEncoding() - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
getEncoding() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
getEncoding() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
getEndColumn() - Method in class org.apache.qpid.filter.selector.SimpleCharStream
Get token end column number.
getEndLine() - Method in class org.apache.qpid.filter.selector.SimpleCharStream
Get token end line number.
getEnumeration() - Method in class org.apache.qpid.client.AMQQueueBrowser
 
getEnvironment() - Method in class org.apache.qpid.jndi.ReadOnlyContext
 
getEnvironment() - Method in class org.apache.qpid.naming.ReadOnlyContext
 
getExceptionListener() - Method in class org.apache.qpid.client.AMQConnection
 
getExchange() - Method in class org.apache.qpid.client.AMQDestination.Binding
 
getExchange() - Method in class org.apache.qpid.client.message.UnprocessedMessage_0_8
 
getExchangeClass() - Method in class org.apache.qpid.client.AMQDestination
 
getExchangeName() - Method in class org.apache.qpid.client.AMQDestination
 
getExchangeName() - Method in class org.apache.qpid.client.AMQTopic
 
getExchangeName() - Method in class org.apache.qpid.client.message.ExchangeInfo
 
getExchangeType() - Method in class org.apache.qpid.client.message.ExchangeInfo
 
getExchangeType() - Method in class org.apache.qpid.client.messaging.address.Node.ExchangeNode
 
getExpressionSymbol() - Method in class org.apache.qpid.filter.BinaryExpression
Returns the symbol that represents this binary expression.
getExpressionSymbol() - Method in class org.apache.qpid.filter.ComparisonExpression.LikeExpression
org.apache.activemq.filter.UnaryExpression#getExpressionSymbol()
getExpressionSymbol() - Method in class org.apache.qpid.filter.UnaryExpression
Returns the symbol that represents this binary expression.
getFailoverLatch() - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
 
getFailoverMethod() - Method in class org.apache.qpid.client.AMQConnectionURL
 
getFailoverMethod() - Method in interface org.apache.qpid.jms.ConnectionURL
 
getFailoverMutex() - Method in class org.apache.qpid.client.AMQConnection
In order to protect the consistency of the connection and its child sessions, consumers and producers, the "failover mutex" must be held when doing any operations that could be corrupted during failover.
getFailoverMutex() - Method in class org.apache.qpid.client.AMQSession
 
getFailoverOption(String) - Method in class org.apache.qpid.client.AMQConnectionURL
 
getFailoverOption(String) - Method in interface org.apache.qpid.jms.ConnectionURL
 
getFailoverOptions() - Method in class org.apache.qpid.client.AMQConnectionURL
 
getFailoverPolicy() - Method in class org.apache.qpid.client.AMQConnection
 
getFailoverState() - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
 
getFilter() - Method in class org.apache.qpid.client.messaging.address.Link
 
getFilterType() - Method in class org.apache.qpid.client.messaging.address.Link
 
getFloat(String) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
getFloat(String) - Method in class org.apache.qpid.client.message.JMSMapMessage
 
getFloatProperty(String) - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
getFloatProperty(String) - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
getFloatProperty(String) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
getFloatProperty(String) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
getFrameMax() - Method in class org.apache.qpid.client.ConnectionTuneParameters
 
getHeader() - Method in class org.apache.qpid.nclient.util.ByteBufferMessage
 
getHeaders() - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
getHeartbeat() - Method in class org.apache.qpid.client.ConnectionTuneParameters
 
getHost() - Method in class org.apache.qpid.client.AMQBrokerDetails
 
getHost() - Method in class org.apache.qpid.client.AMQConnectionFactory
 
getHost() - Method in interface org.apache.qpid.jms.BrokerDetails
 
GetImage() - Method in class org.apache.qpid.filter.selector.SimpleCharStream
Get token literal value.
getInfoFromBindingURL(BindingURL) - Method in class org.apache.qpid.client.AMQDestination
 
getInitialContext(Hashtable) - Method in class org.apache.qpid.jndi.PropertiesFileInitialContextFactory
 
getInstance() - Static method in class org.apache.qpid.client.handler.AccessRequestOkMethodHandler
 
getInstance() - Static method in class org.apache.qpid.client.handler.BasicCancelOkMethodHandler
 
getInstance() - Static method in class org.apache.qpid.client.handler.BasicDeliverMethodHandler
 
getInstance() - Static method in class org.apache.qpid.client.handler.BasicReturnMethodHandler
 
getInstance() - Static method in class org.apache.qpid.client.handler.ChannelCloseMethodHandler
 
getInstance() - Static method in class org.apache.qpid.client.handler.ChannelCloseOkMethodHandler
 
getInstance() - Static method in class org.apache.qpid.client.handler.ChannelFlowMethodHandler
 
getInstance() - Static method in class org.apache.qpid.client.handler.ChannelFlowOkMethodHandler
 
getInstance() - Static method in class org.apache.qpid.client.handler.ConnectionCloseMethodHandler
 
getInstance() - Static method in class org.apache.qpid.client.handler.ConnectionOpenOkMethodHandler
 
getInstance() - Static method in class org.apache.qpid.client.handler.ConnectionRedirectMethodHandler
 
getInstance() - Static method in class org.apache.qpid.client.handler.ConnectionSecureMethodHandler
 
getInstance() - Static method in class org.apache.qpid.client.handler.ConnectionStartMethodHandler
 
getInstance() - Static method in class org.apache.qpid.client.handler.ConnectionTuneMethodHandler
 
getInstance() - Static method in class org.apache.qpid.client.handler.ExchangeBoundOkMethodHandler
 
getInstance() - Static method in class org.apache.qpid.client.handler.QueueDeleteOkMethodHandler
 
getInstance() - Static method in class org.apache.qpid.client.security.CallbackHandlerRegistry
Gets the singleton instance of this registry.
getInstance(BrokerDetails) - Static method in class org.apache.qpid.client.transport.TransportConnection
 
getInt(String) - Method in class org.apache.qpid.client.message.JMSMapMessage
 
getInteger(String) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
getIntProperty(String) - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
getIntProperty(String) - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
getIntProperty(String) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
getIntProperty(String) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
getItem() - Method in class org.apache.qpid.client.MessageConsumerPair
 
getJMSCorrelationID() - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
getJMSCorrelationID() - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
getJMSCorrelationID() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
getJMSCorrelationID() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
getJMSCorrelationIDAsBytes() - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
getJMSCorrelationIDAsBytes() - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
getJMSCorrelationIDAsBytes() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
getJMSCorrelationIDAsBytes() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
getJMSDeliveryMode() - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
getJMSDeliveryMode() - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
getJMSDeliveryMode() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
getJMSDeliveryMode() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
getJMSDestination() - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
getJMSDestination() - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
getJMSDestination() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
getJMSDestination() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
getJMSExpiration() - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
getJMSExpiration() - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
getJMSExpiration() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
getJMSExpiration() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
getJMSMajorVersion() - Method in class org.apache.qpid.client.QpidConnectionMetaData
 
getJMSMessageID() - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
getJMSMessageID() - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
getJMSMessageID() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
getJMSMessageID() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
getJMSMinorVersion() - Method in class org.apache.qpid.client.QpidConnectionMetaData
 
getJMSPriority() - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
getJMSPriority() - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
getJMSPriority() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
getJMSPriority() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
getJMSProviderName() - Method in class org.apache.qpid.client.QpidConnectionMetaData
 
getJMSRedelivered() - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
getJMSReplyTo() - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
getJMSReplyTo() - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
getJMSReplyTo() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
getJMSReplyTo() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
getJMSTimestamp() - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
getJMSTimestamp() - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
getJMSTimestamp() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
getJMSTimestamp() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
getJMSType() - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
getJMSType() - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
getJMSType() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
getJMSType() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
getJMSVersion() - Method in class org.apache.qpid.client.QpidConnectionMetaData
 
getJMSXPropertyNames() - Method in class org.apache.qpid.client.QpidConnectionMetaData
 
getKey() - Method in class org.apache.qpid.collections.keyvalue.AbstractKeyValue
Gets the key from the pair.
getKey() - Method in interface org.apache.qpid.collections.KeyValue
Gets the key from the pair.
getKeystorePassword() - Method in class org.apache.qpid.client.SSLConfiguration
 
getKeystorePath() - Method in class org.apache.qpid.client.SSLConfiguration
 
getLastDelivered() - Method in class org.apache.qpid.client.BasicMessageConsumer
Acknowledge up to last message delivered (if any).
getLastException() - Method in class org.apache.qpid.client.state.AMQStateManager
 
getLastMessageOutputTime() - Method in class org.apache.qpid.client.protocol.ProtocolBufferMonitorFilter
 
getLeft() - Method in class org.apache.qpid.filter.BinaryExpression
 
getLimit() - Method in exception org.apache.qpid.jms.ChannelLimitReachedException
 
getLine() - Method in class org.apache.qpid.filter.selector.SimpleCharStream
Deprecated. 
getLink() - Method in class org.apache.qpid.client.AMQDestination
 
getLink() - Method in class org.apache.qpid.client.messaging.address.AddressHelper
 
getLocalAddress() - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
 
getLong(String) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
getLong(String) - Method in class org.apache.qpid.client.message.JMSMapMessage
 
getLongProperty(String) - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
getLongProperty(String) - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
getLongProperty(String) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
getLongProperty(String) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
getMap() - Method in class org.apache.qpid.client.message.AMQPEncodedMapMessage
 
getMapNames() - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
getMapNames() - Method in class org.apache.qpid.client.message.JMSMapMessage
 
getMaxChannelID() - Method in interface org.apache.qpid.client.AMQConnectionDelegate
 
getMaxChannelID() - Method in class org.apache.qpid.client.AMQConnectionDelegate_0_10
 
getMaxChannelID() - Method in class org.apache.qpid.client.AMQConnectionDelegate_8_0
 
getMaximumChannelCount() - Method in class org.apache.qpid.client.AMQConnection
 
getMaximumChannelCount() - Method in interface org.apache.qpid.jms.Connection
 
getMaximumFrameSize() - Method in class org.apache.qpid.client.AMQConnection
 
getMaxPrefetch() - Method in class org.apache.qpid.client.AMQConnection
Get the maximum number of messages that this connection can pre-fetch.
getMechanismName() - Method in class org.apache.qpid.client.security.amqplain.AmqPlainSaslClient
 
getMechanismNames(Map) - Method in class org.apache.qpid.client.security.amqplain.AmqPlainSaslClientFactory
 
getMechanismNames(Map) - Method in class org.apache.qpid.client.security.crammd5hashed.CRAMMD5HashedSaslClientFactory
 
getMechanisms() - Method in class org.apache.qpid.client.security.CallbackHandlerRegistry
Gets a space delimited list of supported SASL mechanisms.
getMessage() - Method in error org.apache.qpid.filter.selector.TokenMgrError
You can also modify the body of this method to customize your error messages.
getMessageConsumer() - Method in class org.apache.qpid.client.TopicSubscriberAdaptor
 
getMessageDelegateFactory() - Method in class org.apache.qpid.client.AMQSession
 
getMessageDelegateFactory() - Method in class org.apache.qpid.client.AMQSession_0_10
 
getMessageDelegateFactory() - Method in class org.apache.qpid.client.AMQSession_0_8
 
getMessageDeliveryLock() - Method in class org.apache.qpid.client.AMQSession
 
getMessageFromQueue(long) - Method in class org.apache.qpid.client.BasicMessageConsumer
 
getMessageFromQueue(long) - Method in class org.apache.qpid.client.BasicMessageConsumer_0_10
When messages are not prefetched we need to request a message from the broker.
getMessageListener() - Method in class org.apache.qpid.client.AMQQueueSessionAdaptor
 
getMessageListener() - Method in class org.apache.qpid.client.AMQSession
 
getMessageListener() - Method in class org.apache.qpid.client.AMQTopicSessionAdaptor
 
getMessageListener() - Method in class org.apache.qpid.client.BasicMessageConsumer
 
getMessageListener() - Method in class org.apache.qpid.client.QueueReceiverAdaptor
 
getMessageListener() - Method in class org.apache.qpid.client.TopicSubscriberAdaptor
 
getMessageProperties() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
getMessageProperties() - Method in class org.apache.qpid.nclient.util.ByteBufferMessage
 
getMessageSelector() - Method in class org.apache.qpid.client.AMQQueueBrowser
 
getMessageSelector() - Method in class org.apache.qpid.client.BasicMessageConsumer
 
getMessageSelector() - Method in class org.apache.qpid.client.QueueReceiverAdaptor
 
getMessageSelector() - Method in class org.apache.qpid.client.TopicSubscriberAdaptor
 
getMessageTransfer() - Method in class org.apache.qpid.client.message.UnprocessedMessage_0_10
 
getMessageTransferId() - Method in class org.apache.qpid.nclient.util.ByteBufferMessage
 
getMetaData() - Method in class org.apache.qpid.client.AMQConnection
 
getMethodDispatcher() - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
 
getMethodRegistry() - Method in class org.apache.qpid.client.AMQSession
 
getMethodRegistry() - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
 
getMethodRegistry() - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
 
getMimeType() - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
getMimeType() - Method in class org.apache.qpid.client.message.AMQPEncodedMapMessage
 
getMimeType() - Method in class org.apache.qpid.client.message.JMSBytesMessage
 
getMimeType() - Method in class org.apache.qpid.client.message.JMSMapMessage
 
getMimeType() - Method in class org.apache.qpid.client.message.JMSObjectMessage
 
getMimeType() - Method in class org.apache.qpid.client.message.JMSStreamMessage
 
getMimeType() - Method in class org.apache.qpid.client.message.JMSTextMessage
 
getName() - Method in class org.apache.qpid.client.messaging.address.Link
 
getName() - Method in class org.apache.qpid.filter.PropertyExpression
 
getNameInNamespace() - Method in class org.apache.qpid.jndi.ReadOnlyContext
 
getNameInNamespace() - Method in class org.apache.qpid.naming.ReadOnlyContext
 
getNameParser(Name) - Method in class org.apache.qpid.jndi.ReadOnlyContext
 
getNameParser(String) - Method in class org.apache.qpid.jndi.ReadOnlyContext
 
getNameParser(Name) - Method in class org.apache.qpid.naming.ReadOnlyContext
 
getNameParser(String) - Method in class org.apache.qpid.naming.ReadOnlyContext
 
getNegotiatedProperty(String) - Method in class org.apache.qpid.client.security.amqplain.AmqPlainSaslClient
 
getNetworkDriver() - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
 
getNewState() - Method in class org.apache.qpid.client.state.AMQStateChangedEvent
 
getNextBrokerDetails() - Method in class org.apache.qpid.jms.failover.FailoverExchangeMethod
 
getNextBrokerDetails() - Method in interface org.apache.qpid.jms.failover.FailoverMethod
Move to the next BrokerDetails if one is available.
getNextBrokerDetails() - Method in class org.apache.qpid.jms.failover.FailoverRoundRobinServers
 
getNextBrokerDetails() - Method in class org.apache.qpid.jms.failover.FailoverSingleServer
 
getNextBrokerDetails() - Method in class org.apache.qpid.jms.FailoverPolicy
 
getNextChannelId() - Method in class org.apache.qpid.client.AMQConnection.ChannelToSessionMap
 
getNextChannelID() - Method in class org.apache.qpid.client.AMQConnection
 
getNextToken() - Method in class org.apache.qpid.filter.selector.SelectorParser
Get the next Token.
getNextToken() - Method in class org.apache.qpid.filter.selector.SelectorParserTokenManager
Get the next Token.
getNode() - Method in class org.apache.qpid.client.messaging.address.Link
 
getNoLocal() - Method in class org.apache.qpid.client.TopicSubscriberAdaptor
 
getObject(String) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
getObject(String) - Method in class org.apache.qpid.client.message.JMSMapMessage
 
getObject() - Method in class org.apache.qpid.client.message.JMSObjectMessage
 
getObjectInstance(Object, Name, Context, Hashtable) - Method in class org.apache.qpid.client.AMQConnectionFactory
JNDI interface to create objects from References.
getObjectProperty(String) - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
getObjectProperty(String) - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
getObjectProperty(String) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
getObjectProperty(String) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
getOldState() - Method in class org.apache.qpid.client.state.AMQStateChangedEvent
 
getOption(String) - Method in class org.apache.qpid.client.AMQConnectionURL
 
getOption(String) - Static method in enum org.apache.qpid.client.AMQDestination.AddressOption
 
getOption(String) - Method in interface org.apache.qpid.jms.ConnectionURL
 
getOptions() - Method in class org.apache.qpid.client.AMQConnectionURL
 
getOutputFrequencyInMillis() - Method in class org.apache.qpid.client.protocol.ProtocolBufferMonitorFilter
 
getPassword() - Method in class org.apache.qpid.client.AMQConnection
 
getPassword() - Method in class org.apache.qpid.client.AMQConnectionURL
 
getPassword() - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
 
getPassword() - Method in interface org.apache.qpid.jms.ConnectionURL
 
getPort() - Method in class org.apache.qpid.client.AMQBrokerDetails
 
getPort() - Method in class org.apache.qpid.client.AMQConnectionFactory
 
getPort() - Method in interface org.apache.qpid.jms.BrokerDetails
 
getPrefetch() - Method in class org.apache.qpid.client.BasicMessageConsumer
 
getPrefetchHigh() - Method in class org.apache.qpid.client.BasicMessageConsumer
 
getPrefetchLow() - Method in class org.apache.qpid.client.BasicMessageConsumer
 
getPriority() - Method in class org.apache.qpid.client.BasicMessageProducer
 
getPriority() - Method in class org.apache.qpid.client.QueueSenderAdapter
 
getPriority() - Method in class org.apache.qpid.client.TopicPublisherAdapter
 
getProducerCapacity() - Method in class org.apache.qpid.client.messaging.address.Link
 
getProperties() - Method in class org.apache.qpid.client.AMQBrokerDetails
 
getProperties() - Method in interface org.apache.qpid.jms.BrokerDetails
Ex: keystore path
getProperty(String) - Method in class org.apache.qpid.client.AMQBrokerDetails
 
getProperty(String) - Method in interface org.apache.qpid.jms.BrokerDetails
 
getPropertyNames() - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
getPropertyNames() - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
getPropertyNames() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
getPropertyNames() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
getPropertyNames() - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
getProtocolHandler() - Method in class org.apache.qpid.client.AMQConnection
 
getProtocolHandler() - Method in class org.apache.qpid.client.AMQSession
 
getProtocolMajorVersion() - Method in class org.apache.qpid.client.AMQSession
 
getProtocolMajorVersion() - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
 
getProtocolMajorVersion() - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
 
getProtocolMinorVersion() - Method in class org.apache.qpid.client.AMQSession
 
getProtocolMinorVersion() - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
 
getProtocolMinorVersion() - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
 
getProtocolSession() - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
 
getProtocolVersion() - Method in class org.apache.qpid.client.AMQConnection
 
getProtocolVersion() - Method in interface org.apache.qpid.client.AMQConnectionDelegate
 
getProtocolVersion() - Method in class org.apache.qpid.client.AMQConnectionDelegate_0_10
 
getProtocolVersion() - Method in class org.apache.qpid.client.AMQConnectionDelegate_0_9
 
getProtocolVersion() - Method in class org.apache.qpid.client.AMQConnectionDelegate_8_0
 
getProtocolVersion() - Method in class org.apache.qpid.client.AMQConnectionDelegate_9_1
 
getProtocolVersion() - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
 
getProtocolVersion() - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
 
getProviderMajorVersion() - Method in class org.apache.qpid.client.QpidConnectionMetaData
 
getProviderMinorVersion() - Method in class org.apache.qpid.client.QpidConnectionMetaData
 
getProviderVersion() - Method in class org.apache.qpid.client.QpidConnectionMetaData
 
getQpidConnection() - Method in class org.apache.qpid.client.AMQConnectionDelegate_0_10
 
getQpidSession() - Method in class org.apache.qpid.client.AMQSession_0_10
Access to the underlying Qpid Session
getQpidSession() - Method in class org.apache.qpid.client.XASessionImpl
Access to the underlying Qpid Session
getQueue() - Method in class org.apache.qpid.client.AMQDestination.Binding
 
getQueue() - Method in class org.apache.qpid.client.AMQQueueBrowser
 
getQueue() - Method in class org.apache.qpid.client.QueueReceiverAdaptor
Return the queue associated with this receiver
getQueue() - Method in class org.apache.qpid.client.QueueSenderAdapter
 
getQueueDepth(AMQDestination) - Method in class org.apache.qpid.client.AMQSession
Returns the number of messages currently queued for the given destination.
getQueueName() - Method in class org.apache.qpid.client.AMQDestination
 
getQueuename() - Method in class org.apache.qpid.client.BasicMessageConsumer
 
getQueuePrefix() - Method in class org.apache.qpid.jndi.PropertiesFileInitialContextFactory
 
getQueueSession() - Method in class org.apache.qpid.client.XASessionImpl
Gets the topic session associated with this XATopicSession.
getReadBytes() - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
 
getReference() - Method in class org.apache.qpid.client.AMQConnection
 
getReference() - Method in class org.apache.qpid.client.AMQConnectionFactory
 
getReference() - Method in class org.apache.qpid.client.AMQDestination
 
getRemoteAddress() - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
 
getReplyCode() - Method in class org.apache.qpid.client.message.ReturnMessage
 
getReplyText() - Method in class org.apache.qpid.client.message.ReturnMessage
 
getReplyToString() - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
getReplyToString() - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
getReplyToString() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
getReplyToString() - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
getRight() - Method in class org.apache.qpid.filter.BinaryExpression
 
getRight() - Method in class org.apache.qpid.filter.UnaryExpression
 
getRoutingKey() - Method in class org.apache.qpid.client.AMQDestination
 
getRoutingKey() - Method in class org.apache.qpid.client.AMQQueue
 
getRoutingKey() - Method in class org.apache.qpid.client.AMQTopic
 
getRoutingKey() - Method in class org.apache.qpid.client.message.UnprocessedMessage_0_8
 
getSaslClient() - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
 
getSelector() - Method in class org.apache.qpid.filter.JMSSelectorFilter
 
getSession(int) - Method in class org.apache.qpid.client.AMQConnection
 
getSession() - Method in class org.apache.qpid.client.AMQQueueSessionAdaptor
 
getSession() - Method in interface org.apache.qpid.client.AMQSessionAdapter
 
getSession() - Method in class org.apache.qpid.client.AMQTemporaryQueue
 
getSession() - Method in class org.apache.qpid.client.AMQTemporaryTopic
 
getSession() - Method in class org.apache.qpid.client.AMQTopicSessionAdaptor
 
getSession() - Method in class org.apache.qpid.client.BasicMessageConsumer
 
getSession() - Method in class org.apache.qpid.client.BasicMessageProducer
 
getSession(int) - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
 
getSession() - Method in interface org.apache.qpid.client.TemporaryDestination
 
getSession() - Method in class org.apache.qpid.client.XASessionImpl
Gets the session associated with this XASession.
getSessions() - Method in class org.apache.qpid.client.AMQConnection
 
getShort(String) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
getShort(String) - Method in class org.apache.qpid.client.message.JMSMapMessage
 
getShortProperty(String) - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
getShortProperty(String) - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
getShortProperty(String) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
getShortProperty(String) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
getShortStringName() - Method in enum org.apache.qpid.client.CustomJMSXProperty
 
getSourceNode() - Method in class org.apache.qpid.client.AMQDestination
 
getSourceNode(int) - Method in class org.apache.qpid.client.messaging.address.AddressHelper
if the type == queue x-declare args from the node props is used.
getSSLConfiguration() - Method in class org.apache.qpid.client.AMQBrokerDetails
 
getSSLConfiguration() - Method in class org.apache.qpid.client.AMQConnection
 
getSSLConfiguration() - Method in class org.apache.qpid.client.AMQConnectionFactory
Getter for SSLConfiguration
getSSLConfiguration() - Method in interface org.apache.qpid.jms.BrokerDetails
 
getStateManager() - Method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
getStateManager() - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
 
getStateManager() - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
 
getString(String) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
getString(String) - Method in class org.apache.qpid.client.message.JMSMapMessage
 
getStringProperty(String) - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
getStringProperty(String) - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
getStringProperty(String) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
getStringProperty(String) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
getSubject() - Method in class org.apache.qpid.client.AMQDestination
 
getSubscription() - Method in class org.apache.qpid.client.messaging.address.Link
 
GetSuffix(int) - Method in class org.apache.qpid.filter.selector.SimpleCharStream
Get the suffix.
getSuggestedProtocolVersion() - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
 
getSyncAck() - Method in class org.apache.qpid.client.AMQConnection
Indicates whether we need to sync on every message ack
getSyncPersistence() - Method in class org.apache.qpid.client.AMQConnection
Indicates whether persistent messages are synchronized
getSyncPublish() - Method in class org.apache.qpid.client.AMQConnection
 
getSyntaxType(String) - Static method in enum org.apache.qpid.client.AMQDestination.DestSyntax
 
getTabSize(int) - Method in class org.apache.qpid.filter.selector.SimpleCharStream
 
getTargetNode() - Method in class org.apache.qpid.client.AMQDestination
 
getTargetNode(int) - Method in class org.apache.qpid.client.messaging.address.AddressHelper
 
getTargetNodeType() - Method in class org.apache.qpid.client.messaging.address.AddressHelper
 
getTemporaryQueueExchangeName() - Method in class org.apache.qpid.client.AMQConnection
 
getTemporaryQueueExchangeName() - Method in class org.apache.qpid.client.AMQConnectionURL
 
getTemporaryQueueExchangeName() - Method in class org.apache.qpid.client.AMQSession
 
getTemporaryQueueExchangeName() - Method in interface org.apache.qpid.jms.ConnectionURL
 
getTemporaryQueueExchangeName() - Method in interface org.apache.qpid.jms.Session
 
getTemporaryTopicExchangeName() - Method in class org.apache.qpid.client.AMQConnection
 
getTemporaryTopicExchangeName() - Method in class org.apache.qpid.client.AMQConnectionURL
 
getTemporaryTopicExchangeName() - Method in class org.apache.qpid.client.AMQSession
 
getTemporaryTopicExchangeName() - Method in interface org.apache.qpid.jms.ConnectionURL
 
getTemporaryTopicExchangeName() - Method in interface org.apache.qpid.jms.Session
 
getText() - Method in class org.apache.qpid.client.message.JMSTextMessage
 
getThreshold() - Method in class org.apache.qpid.client.protocol.ProtocolBufferMonitorFilter
 
getTicket() - Method in class org.apache.qpid.client.AMQSession
 
getTimeout() - Method in class org.apache.qpid.client.AMQBrokerDetails
 
getTimeout(int) - Method in class org.apache.qpid.client.protocol.HeartbeatConfig
 
getTimeout() - Method in interface org.apache.qpid.jms.BrokerDetails
 
getTimeoutFactor() - Method in class org.apache.qpid.client.protocol.HeartbeatConfig
 
getTimeToLive() - Method in class org.apache.qpid.client.BasicMessageProducer
 
getTimeToLive() - Method in class org.apache.qpid.client.QueueSenderAdapter
 
getTimeToLive() - Method in class org.apache.qpid.client.TopicPublisherAdapter
 
getToken(int) - Method in class org.apache.qpid.filter.selector.SelectorParser
Get the specific Token.
getTopic() - Method in class org.apache.qpid.client.TopicPublisherAdapter
 
getTopic() - Method in class org.apache.qpid.client.TopicSubscriberAdaptor
 
getTopicName() - Method in class org.apache.qpid.client.AMQAnyDestination
 
getTopicName() - Method in class org.apache.qpid.client.AMQTopic
 
getTopicPrefix() - Method in class org.apache.qpid.jndi.PropertiesFileInitialContextFactory
 
getTopicSession() - Method in class org.apache.qpid.client.XASessionImpl
Gets the topic session associated with this XATopicSession.
getTransacted() - Method in class org.apache.qpid.client.AMQQueueSessionAdaptor
 
getTransacted() - Method in class org.apache.qpid.client.AMQSession
 
getTransacted() - Method in class org.apache.qpid.client.AMQTopicSessionAdaptor
 
getTransactionTimeout() - Method in class org.apache.qpid.client.XAResourceImpl
Obtains the current transaction timeout value set for this XAResource instance.
getTransport() - Method in class org.apache.qpid.client.AMQBrokerDetails
 
getTransport() - Method in interface org.apache.qpid.jms.BrokerDetails
 
getTxnLimit() - Method in class org.apache.qpid.client.ConnectionTuneParameters
 
getType() - Method in class org.apache.qpid.client.messaging.address.Node
 
getUniqueClientID() - Static method in class org.apache.qpid.client.AMQConnectionFactory
 
getURL() - Method in class org.apache.qpid.client.AMQConnectionURL
 
getURL() - Method in class org.apache.qpid.client.url.URLParser_0_10
 
getURL() - Method in interface org.apache.qpid.jms.ConnectionURL
 
getUsername() - Method in class org.apache.qpid.client.AMQConnection
 
getUsername() - Method in class org.apache.qpid.client.AMQConnectionURL
 
getUsername() - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
 
getUsername() - Method in interface org.apache.qpid.jms.ConnectionURL
 
getValue() - Method in class org.apache.qpid.collections.keyvalue.AbstractKeyValue
Gets the value from the pair.
getValue() - Method in interface org.apache.qpid.collections.KeyValue
Gets the value from the pair.
getValue() - Method in class org.apache.qpid.filter.ConstantExpression
 
getValue() - Method in class org.apache.qpid.filter.selector.Token
An optional attribute value of the Token.
getVirtualHost() - Method in class org.apache.qpid.client.AMQConnection
 
getVirtualHost() - Method in class org.apache.qpid.client.AMQConnectionURL
 
getVirtualHost() - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
 
getVirtualHost() - Method in interface org.apache.qpid.jms.ConnectionURL
 
getVirtualPath() - Method in class org.apache.qpid.client.AMQConnectionFactory
 
getWaitTimeout() - Method in class org.apache.qpid.client.state.AMQStateManager
This provides a single place that the maximum time for state change to occur can be accessed.
getWorkerTimeout() - Method in class org.apache.mina.transport.socket.nio.ExistingSocketConnector
How many seconds to keep the connection thread alive between connection requests
getWrittenBytes() - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
 
getXAResource() - Method in class org.apache.qpid.client.XASessionImpl
Returns an XA resource.

H

handle(Callback[]) - Method in class org.apache.qpid.client.security.UsernameHashedPasswordCallbackHandler
 
handle(Callback[]) - Method in class org.apache.qpid.client.security.UsernamePasswordCallbackHandler
 
handleAddressBasedDestination(AMQDestination, boolean, boolean) - Method in class org.apache.qpid.client.AMQSession
 
handleAddressBasedDestination(AMQDestination, boolean, boolean) - Method in class org.apache.qpid.client.AMQSession_0_10
1.
handleAddressBasedDestination(AMQDestination, boolean, boolean) - Method in class org.apache.qpid.client.AMQSession_0_8
 
HARD - Static variable in class org.apache.qpid.collections.ReferenceMap
Deprecated. Constant indicating that hard references should be used.
hasConsumer(Destination) - Method in class org.apache.qpid.client.AMQSession
 
hasFailedOver() - Method in class org.apache.qpid.client.AMQSession
Check to see if failover has occured since the last call to markClean(commit or rollback).
hashCode() - Method in class org.apache.qpid.client.AMQBrokerDetails
 
hashCode() - Method in class org.apache.qpid.client.AMQDestination
 
hashCode() - Method in class org.apache.qpid.client.AMQTopic
 
hashCode() - Method in class org.apache.qpid.collections.keyvalue.AbstractMapEntry
Gets a hashCode compatible with the equals method.
hashCode() - Method in class org.apache.qpid.filter.BinaryExpression
TODO: more efficient hashCode()
hashCode() - Method in class org.apache.qpid.filter.ConstantExpression
TODO: more efficient hashCode()
hashCode() - Method in class org.apache.qpid.filter.PropertyExpression
 
hashCode() - Method in class org.apache.qpid.filter.UnaryExpression
TODO: more efficient hashCode()
hasInitialResponse() - Method in class org.apache.qpid.client.security.amqplain.AmqPlainSaslClient
 
hasMessageListeners() - Method in class org.apache.qpid.client.AMQSession
 
heartbeatBodyReceived(int, HeartbeatBody) - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
 
HeartbeatConfig - Class in org.apache.qpid.client.protocol
 
HeartbeatConfig() - Constructor for class org.apache.qpid.client.protocol.HeartbeatConfig
 
HeartbeatDiagnostics - Class in org.apache.qpid.client.protocol
 
HeartbeatDiagnostics() - Constructor for class org.apache.qpid.client.protocol.HeartbeatDiagnostics
 
HEX_LITERAL - Static variable in interface org.apache.qpid.filter.selector.SelectorParserConstants
RegularExpression Id.

I

ID - Static variable in interface org.apache.qpid.filter.selector.SelectorParserConstants
RegularExpression Id.
image - Variable in class org.apache.qpid.filter.selector.Token
The string image of the token.
IMMEDIATE_PREFETCH - Static variable in class org.apache.qpid.client.AMQSession
System property to enable immediate message prefetching.
IMMEDIATE_PREFETCH_DEFAULT - Static variable in class org.apache.qpid.client.AMQSession
Immediate message prefetch default.
IN - Static variable in interface org.apache.qpid.filter.selector.SelectorParserConstants
RegularExpression Id.
IN_PROGRESS - Static variable in class org.apache.qpid.client.failover.FailoverState
Failover has been requested on this connection but has not completed.
inBuf - Variable in class org.apache.qpid.filter.selector.SimpleCharStream
 
init() - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
 
init(int, int) - Static method in class org.apache.qpid.client.protocol.HeartbeatDiagnostics
 
initHeartbeats(int) - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
 
initialise(AMQProtocolSession) - Method in interface org.apache.qpid.client.security.AMQCallbackHandler
 
initialise(AMQProtocolSession) - Method in class org.apache.qpid.client.security.UsernameHashedPasswordCallbackHandler
 
initialise(AMQProtocolSession) - Method in class org.apache.qpid.client.security.UsernamePasswordCallbackHandler
 
input_stream - Variable in class org.apache.qpid.filter.selector.SelectorParserTokenManager
 
inputStream - Variable in class org.apache.qpid.filter.selector.SimpleCharStream
 
INT_TYPE - Static variable in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
INTEGER - Static variable in class org.apache.qpid.filter.ArithmeticExpression
 
internalBind(String, Object) - Method in class org.apache.qpid.jndi.ReadOnlyContext
internalBind is intended for use only during setup or possibly by suitably synchronized superclasses.
internalBind(String, Object) - Method in class org.apache.qpid.naming.ReadOnlyContext
internalBind is intended for use only during setup or possibly by suitably synchronized superclasses.
INVALID_LEXICAL_STATE - Static variable in error org.apache.qpid.filter.selector.TokenMgrError
Tried to change to an invalid lexical state.
IS - Static variable in interface org.apache.qpid.filter.selector.SelectorParserConstants
RegularExpression Id.
isAddressResolved() - Method in class org.apache.qpid.client.AMQDestination
 
isAllBodyDataReceived() - Method in class org.apache.qpid.client.message.UnprocessedMessage_0_8
 
isAutoClose() - Method in class org.apache.qpid.client.BasicMessageConsumer
 
isAutoDelete() - Method in class org.apache.qpid.client.AMQDestination
 
isAutoDelete() - Method in class org.apache.qpid.client.messaging.address.Node
 
isBound(AMQDestination) - Method in class org.apache.qpid.client.BasicMessageProducer
 
isBound(AMQDestination) - Method in class org.apache.qpid.client.BasicMessageProducer_0_10
 
isBrowseOnly() - Method in class org.apache.qpid.client.AMQDestination
 
isBrowseOnly() - Method in class org.apache.qpid.client.messaging.address.AddressHelper
 
isCheckedForQueueBinding() - Method in class org.apache.qpid.client.AMQDestination
 
isClosed() - Method in class org.apache.qpid.client.AMQSession
Checks if the Session and its parent connection are closed
isClosed() - Method in class org.apache.qpid.client.Closeable
Checks if this is closed.
isClosing() - Method in class org.apache.qpid.client.AMQSession
Checks if the Session and its parent connection are capable of performing closing operations
isClosing() - Method in class org.apache.qpid.client.Closeable
Checks if this is closis.
isComplete() - Method in class org.apache.qpid.client.security.amqplain.AmqPlainSaslClient
 
isDeleted() - Method in class org.apache.qpid.client.AMQTemporaryQueue
 
isDeleted() - Method in class org.apache.qpid.client.AMQTemporaryTopic
 
isDeleted() - Method in interface org.apache.qpid.client.TemporaryDestination
 
isDirty() - Method in class org.apache.qpid.client.AMQSession
Check to see if any message have been sent in this transaction and have not been commited.
isDurable() - Method in class org.apache.qpid.client.AMQDestination
 
isDurable() - Method in class org.apache.qpid.client.messaging.address.Link
 
isDurable() - Method in class org.apache.qpid.client.messaging.address.Node
 
isEmpty() - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
isEmpty() - Method in class org.apache.qpid.client.util.FlowControllingBlockingQueue
 
isEmpty() - Method in class org.apache.qpid.collections.ReferenceMap
Deprecated. Returns true if this map is empty.
isExchangeExist(AMQDestination, Node.ExchangeNode, boolean) - Method in class org.apache.qpid.client.AMQSession_0_10
 
isExchangeExistsChecked() - Method in class org.apache.qpid.client.AMQDestination
 
isExclusive() - Method in class org.apache.qpid.client.AMQDestination
 
isExclusive() - Method in class org.apache.qpid.client.BasicMessageConsumer
 
isExclusive() - Method in class org.apache.qpid.client.BasicMessageConsumer_0_10
 
isExclusive() - Method in class org.apache.qpid.client.messaging.address.Link.Subscription
 
isExclusive() - Method in class org.apache.qpid.client.messaging.address.Node.QueueNode
 
isFailingOver() - Method in class org.apache.qpid.client.AMQConnection
 
isFrozen() - Method in class org.apache.qpid.jndi.ReadOnlyContext
 
isFrozen() - Method in class org.apache.qpid.naming.ReadOnlyContext
 
isInRecovery() - Method in class org.apache.qpid.client.AMQSession
 
isMessageListenerSet() - Method in class org.apache.qpid.client.BasicMessageConsumer
 
isNameRequired() - Method in class org.apache.qpid.client.AMQAnyDestination
 
isNameRequired() - Method in class org.apache.qpid.client.AMQDestination
 
isNameRequired() - Method in class org.apache.qpid.client.AMQHeadersExchange
 
isNameRequired() - Method in class org.apache.qpid.client.AMQQueue
 
isNameRequired() - Method in class org.apache.qpid.client.AMQTopic
 
isNameRequired() - Method in class org.apache.qpid.client.AMQUndefinedDestination
 
isNoConsume() - Method in class org.apache.qpid.client.BasicMessageConsumer
 
isNoLocal() - Method in class org.apache.qpid.client.BasicMessageConsumer
 
isNoLocal() - Method in class org.apache.qpid.client.messaging.address.AddressHelper
 
isNoLocal() - Method in class org.apache.qpid.client.messaging.address.Link
 
isQueue() - Method in class org.apache.qpid.client.AMQDestination
 
isQueueBound(AMQShortString, AMQShortString) - Method in class org.apache.qpid.client.AMQSession
 
isQueueBound(AMQShortString, AMQShortString, AMQShortString) - Method in class org.apache.qpid.client.AMQSession
Tests whether or not the specified queue is bound to the specified exchange under a particular routing key.
isQueueBound(AMQDestination) - Method in class org.apache.qpid.client.AMQSession
 
isQueueBound(String, String, String, Map<String, Object>) - Method in class org.apache.qpid.client.AMQSession
 
isQueueBound(AMQShortString, AMQShortString, AMQShortString) - Method in class org.apache.qpid.client.AMQSession_0_10
Bind a queue with an exchange.
isQueueBound(AMQDestination) - Method in class org.apache.qpid.client.AMQSession_0_10
 
isQueueBound(AMQShortString, AMQShortString, AMQShortString, AMQShortString[]) - Method in class org.apache.qpid.client.AMQSession_0_10
 
isQueueBound(String, String, String, Map<String, Object>) - Method in class org.apache.qpid.client.AMQSession_0_10
 
isQueueBound(AMQDestination) - Method in class org.apache.qpid.client.AMQSession_0_8
 
isQueueBound(AMQShortString, AMQShortString, AMQShortString) - Method in class org.apache.qpid.client.AMQSession_0_8
 
isQueueBound(String, String, String, Map<String, Object>) - Method in class org.apache.qpid.client.AMQSession_0_8
 
isQueueExist(AMQDestination, Node.QueueNode, boolean) - Method in class org.apache.qpid.client.AMQSession_0_10
 
isReceiving() - Method in class org.apache.qpid.client.BasicMessageConsumer
 
isRedelivered() - Method in class org.apache.qpid.client.message.CloseConsumerMessage
 
isRedelivered() - Method in class org.apache.qpid.client.message.UnprocessedMessage_0_8
 
isSameRM(XAResource) - Method in class org.apache.qpid.client.XAResourceImpl
This method is called to determine if the resource manager instance represented by the target object is the same as the resouce manager instance represented by the parameter xaResource.
isStarted() - Method in class org.apache.qpid.client.AMQSession
 
isStrictAMQP() - Method in class org.apache.qpid.client.AMQSession
 
isSuspended() - Method in class org.apache.qpid.client.AMQSession
 
isTopic() - Method in class org.apache.qpid.client.AMQDestination
 
isUseLegacyMapMessageFormat() - Method in class org.apache.qpid.client.AMQConnection
 
itemExists(String) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
itemExists(String) - Method in class org.apache.qpid.client.message.JMSMapMessage
 
iterator() - Method in class org.apache.qpid.client.util.FlowControllingBlockingQueue
 
ITransportConnection - Interface in org.apache.qpid.client.transport
 

J

JCAProvider - Class in org.apache.qpid.client.security
JCAProvider is a security provider for SASL client factories that is configured from a map of SASL mechanism names to client factories implementation class names.
JCAProvider(Map<String, Class<? extends SaslClientFactory>>) - Constructor for class org.apache.qpid.client.security.JCAProvider
Creates the security provider with a map from SASL mechanisms to implementing factories.
jj_input_stream - Variable in class org.apache.qpid.filter.selector.SelectorParser
 
jj_nt - Variable in class org.apache.qpid.filter.selector.SelectorParser
Next token.
jjbitVec0 - Static variable in class org.apache.qpid.filter.selector.SelectorParserTokenManager
 
jjbitVec2 - Static variable in class org.apache.qpid.filter.selector.SelectorParserTokenManager
 
jjFillToken() - Method in class org.apache.qpid.filter.selector.SelectorParserTokenManager
 
jjmatchedKind - Variable in class org.apache.qpid.filter.selector.SelectorParserTokenManager
 
jjmatchedPos - Variable in class org.apache.qpid.filter.selector.SelectorParserTokenManager
 
jjnewStateCnt - Variable in class org.apache.qpid.filter.selector.SelectorParserTokenManager
 
jjnextStates - Static variable in class org.apache.qpid.filter.selector.SelectorParserTokenManager
 
jjround - Variable in class org.apache.qpid.filter.selector.SelectorParserTokenManager
 
jjstrLiteralImages - Static variable in class org.apache.qpid.filter.selector.SelectorParserTokenManager
Token literal values.
jjtoSkip - Static variable in class org.apache.qpid.filter.selector.SelectorParserTokenManager
 
jjtoSpecial - Static variable in class org.apache.qpid.filter.selector.SelectorParserTokenManager
 
jjtoToken - Static variable in class org.apache.qpid.filter.selector.SelectorParserTokenManager
 
JMS_TYPE - Static variable in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
JMS_TYPE - Static variable in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
JMS_TYPE - Static variable in interface org.apache.qpid.jms.Message
 
JMSAMQException - Exception in org.apache.qpid.client
JMSException does not accept wrapped exceptions in its constructor.
JMSAMQException(String, Exception) - Constructor for exception org.apache.qpid.client.JMSAMQException
Creates a JMSException, wrapping another exception class.
JMSAMQException(AMQException) - Constructor for exception org.apache.qpid.client.JMSAMQException
Deprecated. Use the other constructor and write a helpfull message. This one will be deleted.
JMSBytesMessage - Class in org.apache.qpid.client.message
 
JMSBytesMessage(AMQMessageDelegateFactory) - Constructor for class org.apache.qpid.client.message.JMSBytesMessage
 
JMSBytesMessage(AMQMessageDelegateFactory, ByteBuffer) - Constructor for class org.apache.qpid.client.message.JMSBytesMessage
Construct a bytes message with existing data.
JMSBytesMessage(AMQMessageDelegate, ByteBuffer) - Constructor for class org.apache.qpid.client.message.JMSBytesMessage
 
JMSBytesMessageFactory - Class in org.apache.qpid.client.message
 
JMSBytesMessageFactory() - Constructor for class org.apache.qpid.client.message.JMSBytesMessageFactory
 
JMSHeaderAdapter - Class in org.apache.qpid.client.message
 
JMSHeaderAdapter(FieldTable) - Constructor for class org.apache.qpid.client.message.JMSHeaderAdapter
 
JMSMapMessage - Class in org.apache.qpid.client.message
 
JMSMapMessage(AMQMessageDelegateFactory) - Constructor for class org.apache.qpid.client.message.JMSMapMessage
 
JMSMapMessage(AMQMessageDelegateFactory, ByteBuffer) - Constructor for class org.apache.qpid.client.message.JMSMapMessage
 
JMSMapMessage(AMQMessageDelegate, ByteBuffer) - Constructor for class org.apache.qpid.client.message.JMSMapMessage
 
JMSMapMessageFactory - Class in org.apache.qpid.client.message
 
JMSMapMessageFactory() - Constructor for class org.apache.qpid.client.message.JMSMapMessageFactory
 
JmsNotImplementedException - Exception in org.apache.qpid.client
 
JmsNotImplementedException() - Constructor for exception org.apache.qpid.client.JmsNotImplementedException
 
JMSObjectMessage - Class in org.apache.qpid.client.message
 
JMSObjectMessage(AMQMessageDelegateFactory) - Constructor for class org.apache.qpid.client.message.JMSObjectMessage
Creates empty, writable message for use by producers
JMSObjectMessage(AMQMessageDelegate, ByteBuffer) - Constructor for class org.apache.qpid.client.message.JMSObjectMessage
Creates read only message for delivery to consumers
JMSObjectMessageFactory - Class in org.apache.qpid.client.message
 
JMSObjectMessageFactory() - Constructor for class org.apache.qpid.client.message.JMSObjectMessageFactory
 
JmsSelector() - Method in class org.apache.qpid.filter.selector.SelectorParser
 
JMSSelectorFilter - Class in org.apache.qpid.filter
 
JMSSelectorFilter(String) - Constructor for class org.apache.qpid.filter.JMSSelectorFilter
 
JMSStreamMessage - Class in org.apache.qpid.client.message
 
JMSStreamMessage(AMQMessageDelegateFactory) - Constructor for class org.apache.qpid.client.message.JMSStreamMessage
 
JMSStreamMessage(AMQMessageDelegateFactory, ByteBuffer) - Constructor for class org.apache.qpid.client.message.JMSStreamMessage
Construct a stream message with existing data.
JMSStreamMessage(AMQMessageDelegate, ByteBuffer) - Constructor for class org.apache.qpid.client.message.JMSStreamMessage
 
JMSStreamMessageFactory - Class in org.apache.qpid.client.message
 
JMSStreamMessageFactory() - Constructor for class org.apache.qpid.client.message.JMSStreamMessageFactory
 
JMSTextMessage - Class in org.apache.qpid.client.message
 
JMSTextMessage(AMQMessageDelegateFactory) - Constructor for class org.apache.qpid.client.message.JMSTextMessage
 
JMSTextMessage(AMQMessageDelegateFactory, ByteBuffer, String) - Constructor for class org.apache.qpid.client.message.JMSTextMessage
 
JMSTextMessage(AMQMessageDelegate, ByteBuffer) - Constructor for class org.apache.qpid.client.message.JMSTextMessage
 
JMSTextMessageFactory - Class in org.apache.qpid.client.message
 
JMSTextMessageFactory() - Constructor for class org.apache.qpid.client.message.JMSTextMessageFactory
 

K

KEY - Static variable in class org.apache.qpid.client.messaging.address.AddressHelper
 
key - Variable in class org.apache.qpid.collections.keyvalue.AbstractKeyValue
The key
keySet() - Method in class org.apache.qpid.collections.ReferenceMap
Deprecated. Returns a set view of this map's keys.
KeyValue - Interface in org.apache.qpid.collections
Defines a simple key value pair.
killAllVMBrokers() - Static method in class org.apache.qpid.client.transport.TransportConnection
 
killVMBroker(int) - Static method in class org.apache.qpid.client.transport.TransportConnection
 
kind - Variable in class org.apache.qpid.filter.selector.Token
An integer that describes the kind of this token.

L

LAST_WRITE_FUTURE_JOIN_TIMEOUT - Static variable in class org.apache.qpid.client.protocol.AMQProtocolSession
 
left - Variable in class org.apache.qpid.filter.BinaryExpression
 
LEXICAL_ERROR - Static variable in error org.apache.qpid.filter.selector.TokenMgrError
Lexical error occurred.
LexicalError(boolean, int, int, int, String, char) - Static method in error org.apache.qpid.filter.selector.TokenMgrError
Returns a detailed message for the Error when it is thrown by the token manager to indicate a lexical error.
lexStateNames - Static variable in class org.apache.qpid.filter.selector.SelectorParserTokenManager
Lexer state names.
LIKE - Static variable in interface org.apache.qpid.filter.selector.SelectorParserConstants
RegularExpression Id.
likePattern - Variable in class org.apache.qpid.filter.ComparisonExpression.LikeExpression
 
line - Variable in class org.apache.qpid.filter.selector.SimpleCharStream
 
LINE_COMMENT - Static variable in interface org.apache.qpid.filter.selector.SelectorParserConstants
RegularExpression Id.
LINK - Static variable in class org.apache.qpid.client.messaging.address.AddressHelper
 
Link - Class in org.apache.qpid.client.messaging.address
 
Link() - Constructor for class org.apache.qpid.client.messaging.address.Link
 
Link.FilterType - Enum in org.apache.qpid.client.messaging.address
 
Link.Subscription - Class in org.apache.qpid.client.messaging.address
 
Link.Subscription() - Constructor for class org.apache.qpid.client.messaging.address.Link.Subscription
 
list(String) - Method in class org.apache.qpid.jndi.ReadOnlyContext
 
list(Name) - Method in class org.apache.qpid.jndi.ReadOnlyContext
 
list(String) - Method in class org.apache.qpid.naming.ReadOnlyContext
 
list(Name) - Method in class org.apache.qpid.naming.ReadOnlyContext
 
listBindings(String) - Method in class org.apache.qpid.jndi.ReadOnlyContext
 
listBindings(Name) - Method in class org.apache.qpid.jndi.ReadOnlyContext
 
listBindings(String) - Method in class org.apache.qpid.naming.ReadOnlyContext
 
listBindings(Name) - Method in class org.apache.qpid.naming.ReadOnlyContext
 
literal() - Method in class org.apache.qpid.filter.selector.SelectorParser
 
LogicExpression - Class in org.apache.qpid.filter
A filter performing a comparison of two objects
LogicExpression(BooleanExpression, BooleanExpression) - Constructor for class org.apache.qpid.filter.LogicExpression
 
LONG - Static variable in class org.apache.qpid.filter.ArithmeticExpression
 
LONG_TYPE - Static variable in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
lookup(String) - Method in class org.apache.qpid.jndi.ReadOnlyContext
 
lookup(Name) - Method in class org.apache.qpid.jndi.ReadOnlyContext
 
lookup(String) - Method in class org.apache.qpid.naming.ReadOnlyContext
 
lookup(Name) - Method in class org.apache.qpid.naming.ReadOnlyContext
 
lookupLink(String) - Method in class org.apache.qpid.jndi.ReadOnlyContext
 
lookupLink(Name) - Method in class org.apache.qpid.jndi.ReadOnlyContext
 
lookupLink(String) - Method in class org.apache.qpid.naming.ReadOnlyContext
 
lookupLink(Name) - Method in class org.apache.qpid.naming.ReadOnlyContext
 
LOOP_DETECTED - Static variable in error org.apache.qpid.filter.selector.TokenMgrError
Detected (and bailed out of) an infinite loop in the token manager.

M

main(String[]) - Static method in class org.apache.qpid.client.AMQConnectionURL
 
main(String[]) - Static method in class org.apache.qpid.client.url.URLParser_0_10
 
makeBrokerConnection(BrokerDetails) - Method in class org.apache.qpid.client.AMQConnection
 
makeBrokerConnection(BrokerDetails) - Method in interface org.apache.qpid.client.AMQConnectionDelegate
 
makeBrokerConnection(BrokerDetails) - Method in class org.apache.qpid.client.AMQConnectionDelegate_0_10
Make a connection with the broker
makeBrokerConnection(BrokerDetails) - Method in class org.apache.qpid.client.AMQConnectionDelegate_8_0
 
markClean() - Method in class org.apache.qpid.client.AMQSession
Signifies that the session has no pending sends to commit.
markClosed() - Method in class org.apache.qpid.client.AMQSession
Called to mark the session as being closed.
markClosed() - Method in class org.apache.qpid.client.BasicMessageConsumer
Called when you need to invalidate a consumer.
markDirty() - Method in class org.apache.qpid.client.AMQSession
Signifies that the session has pending sends to commit.
matches(AbstractJMSMessage) - Method in interface org.apache.qpid.filter.BooleanExpression
 
matches(AbstractJMSMessage) - Method in class org.apache.qpid.filter.ComparisonExpression.LikeExpression
 
matches(AbstractJMSMessage) - Method in class org.apache.qpid.filter.ComparisonExpression
 
matches(AbstractJMSMessage) - Method in class org.apache.qpid.filter.ConstantExpression.BooleanConstantExpression
 
matches(AbstractJMSMessage) - Method in class org.apache.qpid.filter.JMSSelectorFilter
 
matches(AbstractJMSMessage) - Method in class org.apache.qpid.filter.LogicExpression
 
matches(AbstractJMSMessage) - Method in interface org.apache.qpid.filter.MessageFilter
 
matches(AbstractJMSMessage) - Method in class org.apache.qpid.filter.UnaryExpression.BooleanUnaryExpression
 
maxNextCharInd - Variable in class org.apache.qpid.filter.selector.SimpleCharStream
 
MECHANISM - Static variable in class org.apache.qpid.client.security.amqplain.AmqPlainSaslClient
The name of this mechanism
MECHANISM - Static variable in class org.apache.qpid.client.security.crammd5hashed.CRAMMD5HashedSaslClientFactory
The name of this mechanism
message(Session, MessageTransfer) - Method in class org.apache.qpid.client.AMQSession_0_10
 
Message - Interface in org.apache.qpid.jms
 
messageAcknowledge(RangeSet, boolean) - Method in class org.apache.qpid.client.AMQSession_0_10
 
messageAcknowledge(RangeSet, boolean, boolean) - Method in class org.apache.qpid.client.AMQSession_0_10
 
MessageConsumer - Interface in org.apache.qpid.jms
 
MessageConsumerPair - Class in org.apache.qpid.client
 
MessageConsumerPair(BasicMessageConsumer, Object) - Constructor for class org.apache.qpid.client.MessageConsumerPair
 
MessageConverter - Class in org.apache.qpid.client.message
 
MessageConverter(AbstractJMSMessage) - Constructor for class org.apache.qpid.client.message.MessageConverter
 
MessageConverter(AMQSession, BytesMessage) - Constructor for class org.apache.qpid.client.message.MessageConverter
 
MessageConverter(AMQSession, MapMessage) - Constructor for class org.apache.qpid.client.message.MessageConverter
 
MessageConverter(AMQSession, ObjectMessage) - Constructor for class org.apache.qpid.client.message.MessageConverter
 
MessageConverter(AMQSession, TextMessage) - Constructor for class org.apache.qpid.client.message.MessageConverter
 
MessageConverter(AMQSession, StreamMessage) - Constructor for class org.apache.qpid.client.message.MessageConverter
 
MessageConverter(AMQSession, Message) - Constructor for class org.apache.qpid.client.message.MessageConverter
 
MessageFactory - Interface in org.apache.qpid.client.message
 
MessageFactoryRegistry - Class in org.apache.qpid.client.message
 
MessageFactoryRegistry() - Constructor for class org.apache.qpid.client.message.MessageFactoryRegistry
 
MessageFilter - Interface in org.apache.qpid.filter
 
MessageListener - Interface in org.apache.qpid.nclient.util
A message listener
MessagePartListener - Interface in org.apache.qpid.nclient
Assembles message parts.
MessagePartListenerAdapter - Class in org.apache.qpid.nclient.util
This is a simple message assembler.
MessagePartListenerAdapter(MessageListener) - Constructor for class org.apache.qpid.nclient.util.MessagePartListenerAdapter
 
MessageProducer - Interface in org.apache.qpid.jms
 
messageReceived(UnprocessedMessage) - Method in class org.apache.qpid.client.AMQSession
Invoked by the MINA IO thread (indirectly) when a message is received from the transport.
messageReceived(UnprocessedMessage) - Method in class org.apache.qpid.client.AMQSession_0_8
 
messageReceived(IoFilter.NextFilter, IoSession, Object) - Method in class org.apache.qpid.client.protocol.ProtocolBufferMonitorFilter
 
messageSent(IoFilter.NextFilter, IoSession, Object) - Method in class org.apache.qpid.client.protocol.ProtocolBufferMonitorFilter
 
messageTransfer(MessageTransfer) - Method in interface org.apache.qpid.nclient.MessagePartListener
Inform the listener of the message transfer
messageTransfer(MessageTransfer) - Method in class org.apache.qpid.nclient.util.MessagePartListenerAdapter
 
methodBodyReceived(int, AMQBody) - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
 
methodFrameReceived(int, AMQMethodBody) - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
 
methodName() - Method in class org.apache.qpid.jms.failover.FailoverExchangeMethod
 
methodName() - Method in interface org.apache.qpid.jms.failover.FailoverMethod
 
methodName() - Method in class org.apache.qpid.jms.failover.FailoverRoundRobinServers
 
methodName() - Method in class org.apache.qpid.jms.failover.FailoverSingleServer
 
methodName() - Method in class org.apache.qpid.jms.failover.NoFailover
 
methodReceived(AMQProtocolSession, AccessRequestOkBody, int) - Method in class org.apache.qpid.client.handler.AccessRequestOkMethodHandler
 
methodReceived(AMQProtocolSession, BasicCancelOkBody, int) - Method in class org.apache.qpid.client.handler.BasicCancelOkMethodHandler
 
methodReceived(AMQProtocolSession, BasicDeliverBody, int) - Method in class org.apache.qpid.client.handler.BasicDeliverMethodHandler
 
methodReceived(AMQProtocolSession, BasicReturnBody, int) - Method in class org.apache.qpid.client.handler.BasicReturnMethodHandler
 
methodReceived(AMQProtocolSession, ChannelCloseBody, int) - Method in class org.apache.qpid.client.handler.ChannelCloseMethodHandler
 
methodReceived(AMQProtocolSession, ChannelCloseOkBody, int) - Method in class org.apache.qpid.client.handler.ChannelCloseOkMethodHandler
 
methodReceived(AMQProtocolSession, ChannelFlowBody, int) - Method in class org.apache.qpid.client.handler.ChannelFlowMethodHandler
 
methodReceived(AMQProtocolSession, ChannelFlowOkBody, int) - Method in class org.apache.qpid.client.handler.ChannelFlowOkMethodHandler
 
methodReceived(AMQProtocolSession, ConnectionCloseBody, int) - Method in class org.apache.qpid.client.handler.ConnectionCloseMethodHandler
 
methodReceived(AMQProtocolSession, ConnectionOpenOkBody, int) - Method in class org.apache.qpid.client.handler.ConnectionOpenOkMethodHandler
 
methodReceived(AMQProtocolSession, ConnectionRedirectBody, int) - Method in class org.apache.qpid.client.handler.ConnectionRedirectMethodHandler
 
methodReceived(AMQProtocolSession, ConnectionSecureBody, int) - Method in class org.apache.qpid.client.handler.ConnectionSecureMethodHandler
 
methodReceived(AMQProtocolSession, ConnectionStartBody, int) - Method in class org.apache.qpid.client.handler.ConnectionStartMethodHandler
 
methodReceived(AMQProtocolSession, ConnectionTuneBody, int) - Method in class org.apache.qpid.client.handler.ConnectionTuneMethodHandler
 
methodReceived(AMQProtocolSession, ExchangeBoundOkBody, int) - Method in class org.apache.qpid.client.handler.ExchangeBoundOkMethodHandler
 
methodReceived(AMQProtocolSession, QueueDeleteOkBody, int) - Method in class org.apache.qpid.client.handler.QueueDeleteOkMethodHandler
 
methodReceived(AMQMethodEvent) - Method in class org.apache.qpid.client.protocol.BlockingMethodFrameListener
Informs this listener that an AMQP method has been received.
methodReceived(AMQMethodEvent<B>) - Method in class org.apache.qpid.client.state.AMQStateManager
 
methodReceived(AMQProtocolSession, B, int) - Method in interface org.apache.qpid.client.state.StateAwareMethodListener
 
MIME_TYPE - Static variable in class org.apache.qpid.client.message.AMQPEncodedMapMessage
 
MIME_TYPE - Static variable in class org.apache.qpid.client.message.JMSBytesMessage
 
MIME_TYPE - Static variable in class org.apache.qpid.client.message.JMSMapMessage
 
MIME_TYPE - Static variable in class org.apache.qpid.client.message.JMSObjectMessage
 
MIME_TYPE - Static variable in class org.apache.qpid.client.message.JMSStreamMessage
 
minus(Number, Number) - Method in class org.apache.qpid.filter.ArithmeticExpression
 
mod(Number, Number) - Method in class org.apache.qpid.filter.ArithmeticExpression
 
MODE - Static variable in class org.apache.qpid.client.messaging.address.AddressHelper
 
multExpr() - Method in class org.apache.qpid.filter.selector.SelectorParser
 
multiply(Number, Number) - Method in class org.apache.qpid.filter.ArithmeticExpression
 

N

NAME - Static variable in class org.apache.qpid.client.messaging.address.AddressHelper
 
name - Variable in class org.apache.qpid.client.messaging.address.Link
 
nameParser - Static variable in class org.apache.qpid.jndi.ReadOnlyContext
 
nameParser - Static variable in class org.apache.qpid.naming.ReadOnlyContext
 
NameParserImpl - Class in org.apache.qpid.jndi
A default implementation of NameParser

Based on class from ActiveMQ.

NameParserImpl() - Constructor for class org.apache.qpid.jndi.NameParserImpl
 
newContext() - Method in class org.apache.qpid.jndi.ReadOnlyContext
 
newContext() - Method in class org.apache.qpid.naming.ReadOnlyContext
 
newDefaultRegistry() - Static method in class org.apache.qpid.client.message.MessageFactoryRegistry
Construct a new registry with the default message factories registered
newMethodDispatcher(ProtocolVersion, AMQProtocolSession) - Static method in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
newSocketConnector() - Method in interface org.apache.qpid.client.transport.SocketTransportConnection.SocketConnectorFactory
 
newToken(int, String) - Static method in class org.apache.qpid.filter.selector.Token
Returns a new Token object, by default.
newToken(int) - Static method in class org.apache.qpid.filter.selector.Token
 
next - Variable in class org.apache.qpid.filter.selector.Token
A reference to the next regular (non-special) token from the input stream.
NO_ACKNOWLEDGE - Static variable in interface org.apache.qpid.jms.Session
Indicates that no client acknowledgements are required.
NO_FAILOVER - Static variable in interface org.apache.qpid.jms.failover.FailoverMethod
 
NO_LOCAL - Static variable in class org.apache.qpid.client.messaging.address.AddressHelper
 
NODE - Static variable in class org.apache.qpid.client.messaging.address.AddressHelper
 
node - Variable in class org.apache.qpid.client.messaging.address.Link
 
Node - Class in org.apache.qpid.client.messaging.address
 
Node() - Constructor for class org.apache.qpid.client.messaging.address.Node
 
Node.ExchangeNode - Class in org.apache.qpid.client.messaging.address
 
Node.ExchangeNode() - Constructor for class org.apache.qpid.client.messaging.address.Node.ExchangeNode
 
Node.QueueNode - Class in org.apache.qpid.client.messaging.address
 
Node.QueueNode() - Constructor for class org.apache.qpid.client.messaging.address.Node.QueueNode
 
Node.UnknownNodeType - Class in org.apache.qpid.client.messaging.address
 
Node.UnknownNodeType() - Constructor for class org.apache.qpid.client.messaging.address.Node.UnknownNodeType
 
NoFailover - Class in org.apache.qpid.jms.failover
Extend the Single Server Model to gain retry functionality but once connected do not attempt to failover.
NoFailover(BrokerDetails) - Constructor for class org.apache.qpid.jms.failover.NoFailover
 
NoFailover(ConnectionURL) - Constructor for class org.apache.qpid.jms.failover.NoFailover
 
NOT - Static variable in interface org.apache.qpid.filter.selector.SelectorParserConstants
RegularExpression Id.
NOT_STARTED - Static variable in class org.apache.qpid.client.failover.FailoverState
Failover has not yet been attempted on this connection.
notifyCloseMessage(CloseConsumerMessage) - Method in class org.apache.qpid.client.BasicMessageConsumer
 
notifyError(Throwable) - Method in class org.apache.qpid.client.BasicMessageConsumer
 
notifyError(Exception) - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
 
notifyFailoverStarting() - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
 
notifyMessage(U) - Method in class org.apache.qpid.client.BasicMessageConsumer
Called from the AMQSession when a message has arrived for this consumer.
notifyMessage(AbstractJMSMessage) - Method in class org.apache.qpid.client.BasicMessageConsumer
 
notifyMessage(AbstractJMSMessage) - Method in class org.apache.qpid.client.BasicMessageConsumer_0_10
This is invoked by the session thread when emptying the session message queue.
notifyMessage(UnprocessedMessage_0_10) - Method in class org.apache.qpid.client.BasicMessageConsumer_0_10
 
NULL - Static variable in class org.apache.qpid.filter.ConstantExpression
 
NULL - Static variable in interface org.apache.qpid.filter.selector.SelectorParserConstants
RegularExpression Id.
NULL_STRING_TYPE - Static variable in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 

O

OCTAL_LITERAL - Static variable in interface org.apache.qpid.filter.selector.SelectorParserConstants
RegularExpression Id.
onMessage(Message) - Method in class org.apache.qpid.jms.failover.FailoverExchangeMethod
 
onMessage(Message) - Method in interface org.apache.qpid.nclient.util.MessageListener
Process an incoming message.
opened(Connection) - Method in class org.apache.qpid.client.AMQConnectionDelegate_0_10
 
opened(Session) - Method in class org.apache.qpid.client.AMQSession_0_10
 
operation - Variable in class org.apache.qpid.client.failover.FailoverNoopSupport
The protected operation that is to be retried in the event of fail-over.
operation - Variable in class org.apache.qpid.client.failover.FailoverRetrySupport
The protected operation that is to be retried in the event of fail-over.
OPTIONS_BROKERLIST - Static variable in interface org.apache.qpid.jms.ConnectionURL
 
OPTIONS_CONNECT_DELAY - Static variable in interface org.apache.qpid.jms.BrokerDetails
 
OPTIONS_CONNECT_TIMEOUT - Static variable in interface org.apache.qpid.jms.BrokerDetails
 
OPTIONS_DEFAULT_QUEUE_EXCHANGE - Static variable in interface org.apache.qpid.jms.ConnectionURL
 
OPTIONS_DEFAULT_TOPIC_EXCHANGE - Static variable in interface org.apache.qpid.jms.ConnectionURL
 
OPTIONS_FAILOVER - Static variable in interface org.apache.qpid.jms.ConnectionURL
 
OPTIONS_FAILOVER_CYCLE - Static variable in interface org.apache.qpid.jms.ConnectionURL
 
OPTIONS_HEARTBEAT - Static variable in interface org.apache.qpid.jms.BrokerDetails
 
OPTIONS_IDLE_TIMEOUT - Static variable in interface org.apache.qpid.jms.BrokerDetails
 
OPTIONS_KEY_STORE - Static variable in interface org.apache.qpid.jms.BrokerDetails
 
OPTIONS_KEY_STORE_PASSWORD - Static variable in interface org.apache.qpid.jms.BrokerDetails
 
OPTIONS_MAXPREFETCH - Static variable in interface org.apache.qpid.jms.ConnectionURL
 
OPTIONS_RETRY - Static variable in interface org.apache.qpid.jms.BrokerDetails
 
OPTIONS_SASL_ENCRYPTION - Static variable in interface org.apache.qpid.jms.BrokerDetails
 
OPTIONS_SASL_MECHS - Static variable in interface org.apache.qpid.jms.BrokerDetails
 
OPTIONS_SASL_PROTOCOL_NAME - Static variable in interface org.apache.qpid.jms.BrokerDetails
 
OPTIONS_SASL_SERVER_NAME - Static variable in interface org.apache.qpid.jms.BrokerDetails
 
OPTIONS_SSL - Static variable in interface org.apache.qpid.jms.BrokerDetails
 
OPTIONS_SSL_CERT_ALIAS - Static variable in interface org.apache.qpid.jms.BrokerDetails
 
OPTIONS_SSL_VERIFY_HOSTNAME - Static variable in interface org.apache.qpid.jms.BrokerDetails
 
OPTIONS_SYNC_ACK - Static variable in interface org.apache.qpid.jms.ConnectionURL
 
OPTIONS_SYNC_PERSISTENCE - Static variable in interface org.apache.qpid.jms.ConnectionURL
 
OPTIONS_SYNC_PUBLISH - Static variable in interface org.apache.qpid.jms.ConnectionURL
 
OPTIONS_TCP_NO_DELAY - Static variable in interface org.apache.qpid.jms.BrokerDetails
 
OPTIONS_TEMPORARY_QUEUE_EXCHANGE - Static variable in interface org.apache.qpid.jms.ConnectionURL
 
OPTIONS_TEMPORARY_TOPIC_EXCHANGE - Static variable in interface org.apache.qpid.jms.ConnectionURL
 
OPTIONS_TRUST_STORE - Static variable in interface org.apache.qpid.jms.BrokerDetails
 
OPTIONS_TRUST_STORE_PASSWORD - Static variable in interface org.apache.qpid.jms.BrokerDetails
 
OPTIONS_USE_LEGACY_MAP_MESSAGE_FORMAT - Static variable in interface org.apache.qpid.jms.ConnectionURL
 
OR - Static variable in interface org.apache.qpid.filter.selector.SelectorParserConstants
RegularExpression Id.
orExpression() - Method in class org.apache.qpid.filter.selector.SelectorParser
 
org.apache.mina.transport.socket.nio - package org.apache.mina.transport.socket.nio
 
org.apache.qpid.client - package org.apache.qpid.client
 
org.apache.qpid.client.failover - package org.apache.qpid.client.failover
 
org.apache.qpid.client.handler - package org.apache.qpid.client.handler
 
org.apache.qpid.client.message - package org.apache.qpid.client.message
 
org.apache.qpid.client.messaging.address - package org.apache.qpid.client.messaging.address
 
org.apache.qpid.client.protocol - package org.apache.qpid.client.protocol
 
org.apache.qpid.client.security - package org.apache.qpid.client.security
 
org.apache.qpid.client.security.amqplain - package org.apache.qpid.client.security.amqplain
 
org.apache.qpid.client.security.crammd5hashed - package org.apache.qpid.client.security.crammd5hashed
 
org.apache.qpid.client.state - package org.apache.qpid.client.state
 
org.apache.qpid.client.state.listener - package org.apache.qpid.client.state.listener
 
org.apache.qpid.client.transport - package org.apache.qpid.client.transport
 
org.apache.qpid.client.url - package org.apache.qpid.client.url
 
org.apache.qpid.client.util - package org.apache.qpid.client.util
 
org.apache.qpid.client.vmbroker - package org.apache.qpid.client.vmbroker
 
org.apache.qpid.collections - package org.apache.qpid.collections
 
org.apache.qpid.collections.keyvalue - package org.apache.qpid.collections.keyvalue
 
org.apache.qpid.filter - package org.apache.qpid.filter
 
org.apache.qpid.filter.selector - package org.apache.qpid.filter.selector
 
org.apache.qpid.jms - package org.apache.qpid.jms
 
org.apache.qpid.jms.failover - package org.apache.qpid.jms.failover
 
org.apache.qpid.jndi - package org.apache.qpid.jndi
 
org.apache.qpid.naming - package org.apache.qpid.naming
 
org.apache.qpid.nclient - package org.apache.qpid.nclient
 
org.apache.qpid.nclient.util - package org.apache.qpid.nclient.util
 

P

parse(String) - Method in class org.apache.qpid.filter.selector.SelectorParser
 
parse(String) - Method in class org.apache.qpid.jndi.NameParserImpl
 
ParseException - Exception in org.apache.qpid.filter.selector
This exception is thrown when parse errors are encountered.
ParseException(Token, int[][], String[]) - Constructor for exception org.apache.qpid.filter.selector.ParseException
This constructor is used by the method "generateParseException" in the generated parser.
ParseException() - Constructor for exception org.apache.qpid.filter.selector.ParseException
The following constructors are for use by you for whatever purpose you can think of.
ParseException(String) - Constructor for exception org.apache.qpid.filter.selector.ParseException
Constructor with message.
PASSWORD - Static variable in interface org.apache.qpid.jms.BrokerDetails
 
performConnectionTask(Runnable) - Method in class org.apache.qpid.client.AMQConnection
 
plus(Number, Number) - Method in class org.apache.qpid.filter.ArithmeticExpression
 
populateMapFromData() - Method in class org.apache.qpid.client.message.AMQPEncodedMapMessage
 
populateMapFromData() - Method in class org.apache.qpid.client.message.JMSMapMessage
 
postDeliver(AbstractJMSMessage) - Method in class org.apache.qpid.client.BasicMessageConsumer
 
postDeliver(AbstractJMSMessage) - Method in class org.apache.qpid.client.BasicMessageConsumer_0_10
 
PRE_ACKNOWLEDGE - Static variable in interface org.apache.qpid.jms.Session
Pre acknowledge means that an ack is sent per message but sent before user code has processed the message (i.e.
preApplicationProcessing(AbstractJMSMessage) - Method in class org.apache.qpid.client.BasicMessageConsumer
 
preApplicationProcessing(AbstractJMSMessage) - Method in class org.apache.qpid.client.BasicMessageConsumer_0_10
 
preDeliver(AbstractJMSMessage) - Method in class org.apache.qpid.client.BasicMessageConsumer
 
preFailover(boolean) - Method in interface org.apache.qpid.jms.ConnectionListener
Called after the infrastructure has detected that failover is required but before attempting failover.
prefetch() - Method in class org.apache.qpid.client.AMQSession
Indicates whether this session consumers pre-fetche messages
prepare(Xid) - Method in class org.apache.qpid.client.XAResourceImpl
Prepare for a transaction commit of the transaction specified in Xid.
prepareForSending() - Method in class org.apache.qpid.client.message.AbstractJMSMessage
Invoked prior to sending the message.
prepareForSending() - Method in class org.apache.qpid.client.message.JMSTextMessage
 
preResubscribe() - Method in interface org.apache.qpid.jms.ConnectionListener
Called after connection has been made to another broker after failover has been started but before any resubscription has been done.
prevCharIsCR - Variable in class org.apache.qpid.filter.selector.SimpleCharStream
 
prevCharIsLF - Variable in class org.apache.qpid.filter.selector.SimpleCharStream
 
primaryExpr() - Method in class org.apache.qpid.filter.selector.SelectorParser
 
process(AMQMethodEvent) - Method in class org.apache.qpid.client.protocol.BlockingMethodFrameListener
 
process(AMQState) - Method in class org.apache.qpid.client.state.StateWaiter
When the state is changed this StateWaiter is notified to process the change.
process(T) - Method in class org.apache.qpid.client.util.BlockingWaiter
Delegates processing of the incomming object to the handler.
processMethod(int, AMQMethodBody) - Method in class org.apache.qpid.client.AMQSession_0_8.QueueDeclareOkHandler
 
processMethod(int, AMQMethodBody) - Method in class org.apache.qpid.client.protocol.BlockingMethodFrameListener
Delegates any additional handling of the incoming methods to another handler.
processMethod(int, AMQMethodBody) - Method in class org.apache.qpid.client.state.listener.SpecificMethodFrameListener
 
propagateExceptionToAllWaiters(Exception) - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
There are two cases where we have other threads potentially blocking for events to be handled by this class.
propagateExceptionToFrameListeners(Exception) - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
This caters for the case where we only need to propogate an exception to the the frame listeners to interupt any protocol level waits.
PropertiesFileInitialContextFactory - Class in org.apache.qpid.jndi
 
PropertiesFileInitialContextFactory() - Constructor for class org.apache.qpid.jndi.PropertiesFileInitialContextFactory
 
propertyExists(String) - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
propertyExists(String) - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
propertyExists(String) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
propertyExists(String) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
propertyExists(AMQShortString) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
propertyExists(String) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
PropertyExpression - Class in org.apache.qpid.filter
Represents a property expression
PropertyExpression(String) - Constructor for class org.apache.qpid.filter.PropertyExpression
 
PROTOCOL_INITIATION_RECEIVED - Static variable in class org.apache.qpid.client.protocol.AMQProtocolSession
 
PROTOCOL_TCP - Static variable in interface org.apache.qpid.jms.BrokerDetails
 
PROTOCOL_TLS - Static variable in interface org.apache.qpid.jms.BrokerDetails
 
ProtocolBufferMonitorFilter - Class in org.apache.qpid.client.protocol
A MINA filter that monitors the numbers of messages pending to be sent by MINA.
ProtocolBufferMonitorFilter() - Constructor for class org.apache.qpid.client.protocol.ProtocolBufferMonitorFilter
 
ProtocolBufferMonitorFilter(int, long) - Constructor for class org.apache.qpid.client.protocol.ProtocolBufferMonitorFilter
 
publish(Message, int, int, long) - Method in class org.apache.qpid.client.QueueSenderAdapter
 
publish(Message) - Method in class org.apache.qpid.client.TopicPublisherAdapter
 
publish(Topic, Message) - Method in class org.apache.qpid.client.TopicPublisherAdapter
 
publish(Message, int, int, long) - Method in class org.apache.qpid.client.TopicPublisherAdapter
 
publish(Topic, Message, int, int, long) - Method in class org.apache.qpid.client.TopicPublisherAdapter
 
publishMode - Variable in class org.apache.qpid.client.BasicMessageProducer
 
put(int, AMQSession) - Method in class org.apache.qpid.client.AMQConnection.ChannelToSessionMap
 
put(int, C) - Method in class org.apache.qpid.client.AMQSession.IdToConsumerMap
 
put(Object, Object) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
put(Object, Object) - Method in class org.apache.qpid.collections.ReferenceMap
Deprecated. Associates the given key with the given value.

Q

QPID_EXCLUSIVE_BINDING - Static variable in class org.apache.qpid.client.messaging.address.QpidExchangeOptions
 
QPID_INITIAL_VALUE_EXCHANGE - Static variable in class org.apache.qpid.client.messaging.address.QpidExchangeOptions
 
QPID_LAST_VALUE_QUEUE - Static variable in class org.apache.qpid.client.messaging.address.QpidQueueOptions
 
QPID_LAST_VALUE_QUEUE_NO_BROWSE - Static variable in class org.apache.qpid.client.messaging.address.QpidQueueOptions
 
QPID_LVQ_KEY - Static variable in class org.apache.qpid.client.messaging.address.QpidQueueOptions
 
QPID_MAX_COUNT - Static variable in class org.apache.qpid.client.messaging.address.QpidQueueOptions
 
QPID_MAX_SIZE - Static variable in class org.apache.qpid.client.messaging.address.QpidQueueOptions
 
QPID_MSG_SEQUENCE - Static variable in class org.apache.qpid.client.messaging.address.QpidExchangeOptions
 
QPID_PERSIST_LAST_NODE - Static variable in class org.apache.qpid.client.messaging.address.QpidQueueOptions
 
QPID_POLICY_TYPE - Static variable in class org.apache.qpid.client.messaging.address.QpidQueueOptions
 
QPID_QUEUE_EVENT_GENERATION - Static variable in class org.apache.qpid.client.messaging.address.QpidQueueOptions
 
QpidConnectionMetaData - Class in org.apache.qpid.client
 
QpidConnectionMetaData(AMQConnection) - Constructor for class org.apache.qpid.client.QpidConnectionMetaData
 
QpidExchangeOptions - Class in org.apache.qpid.client.messaging.address
 
QpidExchangeOptions() - Constructor for class org.apache.qpid.client.messaging.address.QpidExchangeOptions
 
QpidQueueOptions - Class in org.apache.qpid.client.messaging.address
 
QpidQueueOptions() - Constructor for class org.apache.qpid.client.messaging.address.QpidQueueOptions
 
queue - Variable in class org.apache.qpid.client.AMQDestination.Binding
 
QUEUE - Static variable in class org.apache.qpid.client.messaging.address.AddressHelper
 
QUEUE_TYPE - Static variable in class org.apache.qpid.client.AMQDestination
 
QueueDeleteOkMethodHandler - Class in org.apache.qpid.client.handler
 
QueueReceiverAdaptor - Class in org.apache.qpid.client
Class that wraps a MessageConsumer for backwards JMS compatibility Returned by methods in AMQSession etc
QueueReceiverAdaptor(Queue, MessageConsumer) - Constructor for class org.apache.qpid.client.QueueReceiverAdaptor
 
QueueSenderAdapter - Class in org.apache.qpid.client
 
QueueSenderAdapter(BasicMessageProducer, Queue) - Constructor for class org.apache.qpid.client.QueueSenderAdapter
 
QUOTED_ID - Static variable in interface org.apache.qpid.filter.selector.SelectorParserConstants
RegularExpression Id.

R

RANDOM - Static variable in interface org.apache.qpid.jms.failover.FailoverMethod
 
readBoolean() - Method in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
readBoolean() - Method in class org.apache.qpid.client.message.JMSBytesMessage
 
readBoolean() - Method in class org.apache.qpid.client.message.JMSStreamMessage
 
readByte() - Method in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
readByte() - Method in class org.apache.qpid.client.message.JMSBytesMessage
 
readByte() - Method in class org.apache.qpid.client.message.JMSStreamMessage
 
readBytes(byte[]) - Method in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
readBytes(byte[]) - Method in class org.apache.qpid.client.message.JMSBytesMessage
 
readBytes(byte[], int) - Method in class org.apache.qpid.client.message.JMSBytesMessage
 
readBytes(byte[]) - Method in class org.apache.qpid.client.message.JMSStreamMessage
 
readChar() - Method in class org.apache.qpid.client.message.AbstractBytesTypedMessage
Note that this method reads a unicode character as two bytes from the stream
readChar() - Method in class org.apache.qpid.client.message.JMSBytesMessage
Note that this method reads a unicode character as two bytes from the stream
readChar() - Method in class org.apache.qpid.client.message.JMSStreamMessage
Note that this method reads a unicode character as two bytes from the stream
readChar() - Method in class org.apache.qpid.filter.selector.SimpleCharStream
Read a character.
readData(byte[]) - Method in class org.apache.qpid.nclient.util.ByteBufferMessage
 
readData() - Method in class org.apache.qpid.nclient.util.ByteBufferMessage
 
readDouble() - Method in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
readDouble() - Method in class org.apache.qpid.client.message.JMSBytesMessage
 
readDouble() - Method in class org.apache.qpid.client.message.JMSStreamMessage
 
readerIdle() - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
 
readFloat() - Method in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
readFloat() - Method in class org.apache.qpid.client.message.JMSBytesMessage
 
readFloat() - Method in class org.apache.qpid.client.message.JMSStreamMessage
 
readInt() - Method in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
readInt() - Method in class org.apache.qpid.client.message.JMSBytesMessage
 
readInt() - Method in class org.apache.qpid.client.message.JMSStreamMessage
 
readIntImpl() - Method in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
readLong() - Method in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
readLong() - Method in class org.apache.qpid.client.message.JMSBytesMessage
 
readLong() - Method in class org.apache.qpid.client.message.JMSStreamMessage
 
readObject() - Method in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
readObject() - Method in class org.apache.qpid.client.message.JMSStreamMessage
 
ReadOnlyContext - Class in org.apache.qpid.jndi
Based on class from ActiveMQ.
ReadOnlyContext() - Constructor for class org.apache.qpid.jndi.ReadOnlyContext
 
ReadOnlyContext(Hashtable) - Constructor for class org.apache.qpid.jndi.ReadOnlyContext
 
ReadOnlyContext(Hashtable, Map) - Constructor for class org.apache.qpid.jndi.ReadOnlyContext
 
ReadOnlyContext(Hashtable, Map, String) - Constructor for class org.apache.qpid.jndi.ReadOnlyContext
 
ReadOnlyContext(ReadOnlyContext, Hashtable) - Constructor for class org.apache.qpid.jndi.ReadOnlyContext
 
ReadOnlyContext(ReadOnlyContext, Hashtable, String) - Constructor for class org.apache.qpid.jndi.ReadOnlyContext
 
ReadOnlyContext - Class in org.apache.qpid.naming
Based on class from ActiveMQ.
ReadOnlyContext() - Constructor for class org.apache.qpid.naming.ReadOnlyContext
 
ReadOnlyContext(Hashtable) - Constructor for class org.apache.qpid.naming.ReadOnlyContext
 
ReadOnlyContext(Hashtable, Map) - Constructor for class org.apache.qpid.naming.ReadOnlyContext
 
ReadOnlyContext(Hashtable, Map, String) - Constructor for class org.apache.qpid.naming.ReadOnlyContext
 
ReadOnlyContext(ReadOnlyContext, Hashtable) - Constructor for class org.apache.qpid.naming.ReadOnlyContext
 
ReadOnlyContext(ReadOnlyContext, Hashtable, String) - Constructor for class org.apache.qpid.naming.ReadOnlyContext
 
readShort() - Method in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
readShort() - Method in class org.apache.qpid.client.message.JMSBytesMessage
 
readShort() - Method in class org.apache.qpid.client.message.JMSStreamMessage
 
readString() - Method in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
readString() - Method in class org.apache.qpid.client.message.JMSStreamMessage
 
readStringImpl() - Method in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
readUnsignedByte() - Method in class org.apache.qpid.client.message.JMSBytesMessage
 
readUnsignedShort() - Method in class org.apache.qpid.client.message.JMSBytesMessage
 
readUTF() - Method in class org.apache.qpid.client.message.JMSBytesMessage
 
readWireType() - Method in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
rebind(Name, Object) - Method in class org.apache.qpid.jndi.ReadOnlyContext
 
rebind(String, Object) - Method in class org.apache.qpid.jndi.ReadOnlyContext
 
rebind(Name, Object) - Method in class org.apache.qpid.naming.ReadOnlyContext
 
rebind(String, Object) - Method in class org.apache.qpid.naming.ReadOnlyContext
 
rebuildTargetAndSourceNodes(int) - Method in class org.apache.qpid.client.AMQDestination
 
receive() - Method in class org.apache.qpid.client.BasicMessageConsumer
 
receive(long) - Method in class org.apache.qpid.client.BasicMessageConsumer
 
receive() - Method in class org.apache.qpid.client.QueueReceiverAdaptor
 
receive(long) - Method in class org.apache.qpid.client.QueueReceiverAdaptor
 
receive() - Method in class org.apache.qpid.client.TopicSubscriberAdaptor
 
receive(long) - Method in class org.apache.qpid.client.TopicSubscriberAdaptor
 
receiveBody(ContentBody) - Method in class org.apache.qpid.client.message.UnprocessedMessage_0_8
 
receiveBrowse() - Method in class org.apache.qpid.client.BasicMessageConsumer
 
receiveBrowse() - Method in class org.apache.qpid.client.BasicMessageConsumer_0_10
 
receiveBrowse() - Method in class org.apache.qpid.client.BasicMessageConsumer_0_8
 
received(ByteBuffer) - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
 
received(boolean) - Static method in class org.apache.qpid.client.protocol.HeartbeatDiagnostics
 
received(T) - Method in class org.apache.qpid.client.util.BlockingWaiter
An Object has been received and should be processed to see if our wait condition has been reached.
receivedFromServer() - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
receiveNoWait() - Method in class org.apache.qpid.client.BasicMessageConsumer
 
receiveNoWait() - Method in class org.apache.qpid.client.QueueReceiverAdaptor
 
receiveNoWait() - Method in class org.apache.qpid.client.TopicSubscriberAdaptor
 
recover() - Method in class org.apache.qpid.client.AMQQueueSessionAdaptor
 
recover() - Method in class org.apache.qpid.client.AMQSession.Dispatcher
 
recover() - Method in class org.apache.qpid.client.AMQSession
Stops message delivery in this session, and restarts message delivery with the oldest unacknowledged message.
recover() - Method in class org.apache.qpid.client.AMQTopicSessionAdaptor
 
recover(int) - Method in class org.apache.qpid.client.XAResourceImpl
Obtains a list of prepared transaction branches.
ReferenceMap - Class in org.apache.qpid.collections
Deprecated. Moved to map subpackage. Due to be removed in v4.0.
ReferenceMap() - Constructor for class org.apache.qpid.collections.ReferenceMap
Deprecated. Constructs a new ReferenceMap that will use hard references to keys and soft references to values.
ReferenceMap(int, int, boolean) - Constructor for class org.apache.qpid.collections.ReferenceMap
Deprecated. Constructs a new ReferenceMap that will use the specified types of references.
ReferenceMap(int, int) - Constructor for class org.apache.qpid.collections.ReferenceMap
Deprecated. Constructs a new ReferenceMap that will use the specified types of references.
ReferenceMap(int, int, int, float, boolean) - Constructor for class org.apache.qpid.collections.ReferenceMap
Deprecated. Constructs a new ReferenceMap with the specified reference types, load factor and initial capacity.
ReferenceMap(int, int, int, float) - Constructor for class org.apache.qpid.collections.ReferenceMap
Deprecated. Constructs a new ReferenceMap with the specified reference types, load factor and initial capacity.
registerFactory(String, MessageFactory) - Method in class org.apache.qpid.client.message.MessageFactoryRegistry
 
registerOpenSocket(String, Socket) - Static method in class org.apache.qpid.client.transport.TransportConnection
 
registerSaslProviders() - Static method in class org.apache.qpid.client.security.DynamicSaslRegistrar
Reads the properties file, and creates a dynamic security provider to register the SASL implementations with.
registerSession(int, AMQSession) - Method in class org.apache.qpid.client.AMQConnection
 
ReInit(InputStream) - Method in class org.apache.qpid.filter.selector.SelectorParser
Reinitialise.
ReInit(InputStream, String) - Method in class org.apache.qpid.filter.selector.SelectorParser
Reinitialise.
ReInit(Reader) - Method in class org.apache.qpid.filter.selector.SelectorParser
Reinitialise.
ReInit(SelectorParserTokenManager) - Method in class org.apache.qpid.filter.selector.SelectorParser
Reinitialise.
ReInit(SimpleCharStream) - Method in class org.apache.qpid.filter.selector.SelectorParserTokenManager
Reinitialise parser.
ReInit(SimpleCharStream, int) - Method in class org.apache.qpid.filter.selector.SelectorParserTokenManager
Reinitialise parser.
ReInit(Reader, int, int, int) - Method in class org.apache.qpid.filter.selector.SimpleCharStream
Reinitialise.
ReInit(Reader, int, int) - Method in class org.apache.qpid.filter.selector.SimpleCharStream
Reinitialise.
ReInit(Reader) - Method in class org.apache.qpid.filter.selector.SimpleCharStream
Reinitialise.
ReInit(InputStream, String, int, int, int) - Method in class org.apache.qpid.filter.selector.SimpleCharStream
Reinitialise.
ReInit(InputStream, int, int, int) - Method in class org.apache.qpid.filter.selector.SimpleCharStream
Reinitialise.
ReInit(InputStream, String) - Method in class org.apache.qpid.filter.selector.SimpleCharStream
Reinitialise.
ReInit(InputStream) - Method in class org.apache.qpid.filter.selector.SimpleCharStream
Reinitialise.
ReInit(InputStream, String, int, int) - Method in class org.apache.qpid.filter.selector.SimpleCharStream
Reinitialise.
ReInit(InputStream, int, int) - Method in class org.apache.qpid.filter.selector.SimpleCharStream
Reinitialise.
rejectMessage(UnprocessedMessage, boolean) - Method in class org.apache.qpid.client.AMQSession
 
rejectMessage(AbstractJMSMessage, boolean) - Method in class org.apache.qpid.client.AMQSession
 
rejectMessage(long, boolean) - Method in class org.apache.qpid.client.AMQSession
 
rejectMessage(long, boolean) - Method in class org.apache.qpid.client.AMQSession_0_10
Release (0_8 notion of Reject) an acquired message
rejectMessage(long, boolean) - Method in class org.apache.qpid.client.AMQSession_0_8
 
rejectPending(C) - Method in class org.apache.qpid.client.AMQSession.Dispatcher
 
releaseForRollback() - Method in class org.apache.qpid.client.AMQSession
 
releaseForRollback() - Method in class org.apache.qpid.client.AMQSession_0_10
 
releaseForRollback() - Method in class org.apache.qpid.client.AMQSession_0_8
 
RELIABILITY - Static variable in class org.apache.qpid.client.messaging.address.AddressHelper
 
remove(int) - Method in class org.apache.qpid.client.AMQConnection.ChannelToSessionMap
 
remove(int) - Method in class org.apache.qpid.client.AMQSession.IdToConsumerMap
 
remove(AMQShortString) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
remove(String) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
remove(Object) - Method in class org.apache.qpid.collections.ReferenceMap
Deprecated. Removes the key and its associated value from this map.
removeFromEnvironment(String) - Method in class org.apache.qpid.jndi.ReadOnlyContext
 
removeFromEnvironment(String) - Method in class org.apache.qpid.naming.ReadOnlyContext
 
removeOpenSocket(String) - Static method in class org.apache.qpid.client.transport.TransportConnection
 
removeProperty(String) - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
removeProperty(String) - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
removeProperty(String) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
removeProperty(String) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
removeWaiter(StateWaiter) - Method in class org.apache.qpid.client.state.AMQStateManager
Remove the waiter from the notification list.
rename(Name, Name) - Method in class org.apache.qpid.jndi.ReadOnlyContext
 
rename(String, String) - Method in class org.apache.qpid.jndi.ReadOnlyContext
 
rename(Name, Name) - Method in class org.apache.qpid.naming.ReadOnlyContext
 
rename(String, String) - Method in class org.apache.qpid.naming.ReadOnlyContext
 
requestQueueDepth(AMQDestination) - Method in class org.apache.qpid.client.AMQSession
 
requestQueueDepth(AMQDestination) - Method in class org.apache.qpid.client.AMQSession_0_10
 
requestQueueDepth(AMQDestination) - Method in class org.apache.qpid.client.AMQSession_0_8
 
reset() - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
reset() - Method in class org.apache.qpid.client.message.JMSBytesMessage
 
reset() - Method in class org.apache.qpid.client.message.JMSStreamMessage
 
reset() - Method in class org.apache.qpid.jms.failover.FailoverExchangeMethod
 
reset() - Method in interface org.apache.qpid.jms.failover.FailoverMethod
Reset the Failover to initial conditions
reset() - Method in class org.apache.qpid.jms.failover.FailoverRoundRobinServers
 
reset() - Method in class org.apache.qpid.jms.failover.FailoverSingleServer
 
resolveAddressType(AMQDestination) - Method in class org.apache.qpid.client.AMQSession_0_10
 
resubscribe() - Method in class org.apache.qpid.client.AMQSession
Resubscribes all producers and consumers.
resubscribe() - Method in class org.apache.qpid.client.BasicMessageProducer
 
resubscribeSessions() - Method in class org.apache.qpid.client.AMQConnection
 
resubscribeSessions() - Method in interface org.apache.qpid.client.AMQConnectionDelegate
 
resubscribeSessions() - Method in class org.apache.qpid.client.AMQConnectionDelegate_0_10
 
resubscribeSessions() - Method in class org.apache.qpid.client.AMQConnectionDelegate_8_0
For all sessions, and for all consumers in those sessions, resubscribe.
resumed(Session) - Method in class org.apache.qpid.client.AMQSession_0_10
 
ReturnMessage - Class in org.apache.qpid.client.message
 
ReturnMessage(AMQShortString, AMQShortString, AMQShortString, int) - Constructor for class org.apache.qpid.client.message.ReturnMessage
 
right - Variable in class org.apache.qpid.filter.BinaryExpression
 
right - Variable in class org.apache.qpid.filter.UnaryExpression
 
rollback() - Method in class org.apache.qpid.client.AMQQueueSessionAdaptor
 
rollback() - Method in class org.apache.qpid.client.AMQSession.Dispatcher
 
rollback() - Method in class org.apache.qpid.client.AMQSession
Commits all messages done in this transaction and releases any locks currently held.
rollback() - Method in class org.apache.qpid.client.AMQTopicSessionAdaptor
 
rollback() - Method in class org.apache.qpid.client.BasicMessageConsumer
 
rollback(Xid) - Method in class org.apache.qpid.client.XAResourceImpl
Informs the resource manager to roll back work done on behalf of a transaction branch
rollback() - Method in class org.apache.qpid.client.XASessionImpl
Throws a TransactionInProgressException, since it should not be called for an XASession object.
rollbackPendingMessages() - Method in class org.apache.qpid.client.BasicMessageConsumer
 
rollbackPendingMessages() - Method in class org.apache.qpid.client.BasicMessageConsumer_0_10
 
ROUND_ROBIN - Static variable in interface org.apache.qpid.jms.failover.FailoverMethod
 
run() - Method in class org.apache.qpid.client.AMQQueueSessionAdaptor
 
run() - Method in class org.apache.qpid.client.AMQSession.Dispatcher
 
run() - Method in class org.apache.qpid.client.AMQSession
 
run() - Method in class org.apache.qpid.client.AMQTopicSessionAdaptor
 
run() - Method in class org.apache.qpid.client.failover.FailoverHandler
Performs the failover procedure.

S

SASL_CLIENT - Static variable in class org.apache.qpid.client.protocol.AMQProtocolSession
 
SelectorParser - Class in org.apache.qpid.filter.selector
JMS Selector Parser generated by JavaCC Do not edit this .java file directly - it is autogenerated from SelectorParser.jj
SelectorParser() - Constructor for class org.apache.qpid.filter.selector.SelectorParser
 
SelectorParser(InputStream) - Constructor for class org.apache.qpid.filter.selector.SelectorParser
Constructor with InputStream.
SelectorParser(InputStream, String) - Constructor for class org.apache.qpid.filter.selector.SelectorParser
Constructor with InputStream and supplied encoding
SelectorParser(Reader) - Constructor for class org.apache.qpid.filter.selector.SelectorParser
Constructor.
SelectorParser(SelectorParserTokenManager) - Constructor for class org.apache.qpid.filter.selector.SelectorParser
Constructor with generated Token Manager.
SelectorParserConstants - Interface in org.apache.qpid.filter.selector
Token literal values and constants.
SelectorParserTokenManager - Class in org.apache.qpid.filter.selector
Token Manager.
SelectorParserTokenManager(SimpleCharStream) - Constructor for class org.apache.qpid.filter.selector.SelectorParserTokenManager
Constructor.
SelectorParserTokenManager(SimpleCharStream, int) - Constructor for class org.apache.qpid.filter.selector.SelectorParserTokenManager
Constructor.
send(Message) - Method in class org.apache.qpid.client.BasicMessageProducer
 
send(Message, int) - Method in class org.apache.qpid.client.BasicMessageProducer
 
send(Message, int, boolean) - Method in class org.apache.qpid.client.BasicMessageProducer
 
send(Message, int, int, long) - Method in class org.apache.qpid.client.BasicMessageProducer
 
send(Destination, Message) - Method in class org.apache.qpid.client.BasicMessageProducer
 
send(Destination, Message, int, int, long) - Method in class org.apache.qpid.client.BasicMessageProducer
 
send(Destination, Message, int, int, long, boolean) - Method in class org.apache.qpid.client.BasicMessageProducer
 
send(Destination, Message, int, int, long, boolean, boolean) - Method in class org.apache.qpid.client.BasicMessageProducer
 
send(Destination, Message, int, int, long, boolean, boolean, boolean) - Method in class org.apache.qpid.client.BasicMessageProducer
 
send(Message) - Method in class org.apache.qpid.client.QueueSenderAdapter
 
send(Queue, Message) - Method in class org.apache.qpid.client.QueueSenderAdapter
 
send(Queue, Message, int, int, long) - Method in class org.apache.qpid.client.QueueSenderAdapter
 
send(Destination, Message) - Method in class org.apache.qpid.client.QueueSenderAdapter
 
send(Message, int, int, long) - Method in class org.apache.qpid.client.QueueSenderAdapter
 
send(Destination, Message, int, int, long) - Method in class org.apache.qpid.client.QueueSenderAdapter
 
send(Message) - Method in class org.apache.qpid.client.TopicPublisherAdapter
 
send(Destination, Message) - Method in class org.apache.qpid.client.TopicPublisherAdapter
 
send(Message, int, int, long) - Method in class org.apache.qpid.client.TopicPublisherAdapter
 
send(Destination, Message, int, int, long) - Method in class org.apache.qpid.client.TopicPublisherAdapter
 
send(Destination, Message, int, int, long, boolean) - Method in interface org.apache.qpid.jms.MessageProducer
 
send(Destination, Message, int, int, long, boolean, boolean) - Method in interface org.apache.qpid.jms.MessageProducer
 
send(Destination, Message, int, int, long, boolean, boolean, boolean) - Method in interface org.apache.qpid.jms.MessageProducer
 
send0_10QueueDeclare(AMQDestination, AMQProtocolHandler, boolean, boolean) - Method in class org.apache.qpid.client.AMQSession_0_10
Declare a queue with the given queueName
sendCancel() - Method in class org.apache.qpid.client.BasicMessageConsumer
 
sendCancel() - Method in class org.apache.qpid.client.BasicMessageConsumer_0_10
This method is invoked when this consumer is stopped.
sendCancel() - Method in class org.apache.qpid.client.BasicMessageConsumer_0_8
 
sendClose(long) - Method in class org.apache.qpid.client.AMQSession
 
sendClose(long) - Method in class org.apache.qpid.client.AMQSession_0_10
Close this session.
sendClose(long) - Method in class org.apache.qpid.client.AMQSession_0_8
 
sendCommit() - Method in class org.apache.qpid.client.AMQSession
 
sendCommit() - Method in class org.apache.qpid.client.AMQSession_0_10
Commit the receipt and the delivery of all messages exchanged by this session resources.
sendCommit() - Method in class org.apache.qpid.client.AMQSession_0_8
 
sendConsume(C, AMQShortString, AMQProtocolHandler, boolean, String, int) - Method in class org.apache.qpid.client.AMQSession
 
sendConsume(BasicMessageConsumer_0_10, AMQShortString, AMQProtocolHandler, boolean, String, int) - Method in class org.apache.qpid.client.AMQSession_0_10
This method is invoked when a consumer is created Registers the consumer with the broker
sendConsume(BasicMessageConsumer_0_8, AMQShortString, AMQProtocolHandler, boolean, String, int) - Method in class org.apache.qpid.client.AMQSession_0_8
 
sendCreateQueue(AMQShortString, boolean, boolean, boolean, Map<String, Object>) - Method in class org.apache.qpid.client.AMQSession
 
sendCreateQueue(AMQShortString, boolean, boolean, boolean, Map<String, Object>) - Method in class org.apache.qpid.client.AMQSession_0_10
Create a queue with a given name.
sendCreateQueue(AMQShortString, boolean, boolean, boolean, Map<String, Object>) - Method in class org.apache.qpid.client.AMQSession_0_8
 
sendExchangeDeclare(AMQShortString, AMQShortString, AMQProtocolHandler, boolean) - Method in class org.apache.qpid.client.AMQSession
 
sendExchangeDeclare(AMQShortString, AMQShortString, AMQProtocolHandler, boolean) - Method in class org.apache.qpid.client.AMQSession_0_10
creates an exchange if it does not already exist
sendExchangeDeclare(String, String, String, Map<String, Object>, boolean) - Method in class org.apache.qpid.client.AMQSession_0_10
 
sendExchangeDeclare(AMQShortString, AMQShortString, AMQProtocolHandler, boolean) - Method in class org.apache.qpid.client.AMQSession_0_8
 
sendImpl(AMQDestination, Message, int, int, long, boolean, boolean) - Method in class org.apache.qpid.client.BasicMessageProducer
 
sendImpl(AMQDestination, Message, int, int, long, boolean, boolean, boolean) - Method in class org.apache.qpid.client.BasicMessageProducer
The caller of this method must hold the failover mutex.
sendMessage(AMQDestination, Message, AbstractJMSMessage, UUID, int, int, long, boolean, boolean, boolean) - Method in class org.apache.qpid.client.BasicMessageProducer
 
sendMessage(AMQDestination, Message, AbstractJMSMessage, UUID, int, int, long, boolean, boolean, boolean) - Method in class org.apache.qpid.client.BasicMessageProducer_0_10
Sends a message to a given destination
sendMessage(AMQDestination, Message, AbstractJMSMessage, UUID, int, int, long, boolean, boolean, boolean) - Method in class org.apache.qpid.client.BasicMessageProducer_0_8
 
sendQueueBind(AMQShortString, AMQShortString, FieldTable, AMQShortString, AMQDestination, boolean) - Method in class org.apache.qpid.client.AMQSession
 
sendQueueBind(AMQShortString, AMQShortString, FieldTable, AMQShortString, AMQDestination, boolean) - Method in class org.apache.qpid.client.AMQSession_0_10
Bind a queue with an exchange.
sendQueueBind(AMQShortString, AMQShortString, FieldTable, AMQShortString, AMQDestination, boolean) - Method in class org.apache.qpid.client.AMQSession_0_8
 
sendQueueDeclare(AMQDestination, AMQProtocolHandler, boolean) - Method in class org.apache.qpid.client.AMQSession
 
sendQueueDeclare(AMQDestination, AMQProtocolHandler, boolean) - Method in class org.apache.qpid.client.AMQSession_0_10
Declare a queue with the given queueName
sendQueueDeclare(AMQDestination, AMQProtocolHandler, boolean) - Method in class org.apache.qpid.client.AMQSession_0_8
 
sendQueueDelete(AMQShortString) - Method in class org.apache.qpid.client.AMQSession
 
sendQueueDelete(AMQShortString) - Method in class org.apache.qpid.client.AMQSession_0_10
deletes a queue
sendQueueDelete(AMQShortString) - Method in class org.apache.qpid.client.AMQSession_0_8
 
sendRecover() - Method in class org.apache.qpid.client.AMQSession
 
sendRecover() - Method in class org.apache.qpid.client.AMQSession_0_10
This method asks the broker to redeliver all unacknowledged messages
sendRecover() - Method in class org.apache.qpid.client.AMQSession_0_8
 
sendRollback() - Method in class org.apache.qpid.client.AMQSession
 
sendRollback() - Method in class org.apache.qpid.client.AMQSession_0_10
 
sendRollback() - Method in class org.apache.qpid.client.AMQSession_0_8
 
sendSuspendChannel(boolean) - Method in class org.apache.qpid.client.AMQSession
 
sendSuspendChannel(boolean) - Method in class org.apache.qpid.client.AMQSession_0_10
Activate/deactivate the message flow for all the consumers of this session.
sendSuspendChannel(boolean) - Method in class org.apache.qpid.client.AMQSession_0_8
 
sent() - Static method in class org.apache.qpid.client.protocol.HeartbeatDiagnostics
 
SEPARATOR - Static variable in class org.apache.qpid.jndi.ReadOnlyContext
 
SEPARATOR - Static variable in class org.apache.qpid.naming.ReadOnlyContext
 
Session - Interface in org.apache.qpid.jms
 
setAddress(Address) - Method in class org.apache.qpid.client.AMQDestination
 
setAddressName(String) - Method in class org.apache.qpid.client.AMQDestination
 
setAddressResolved(boolean) - Method in class org.apache.qpid.client.AMQDestination
 
setAddressType(int) - Method in class org.apache.qpid.client.AMQDestination
 
setAlternateExchange(String) - Method in class org.apache.qpid.client.messaging.address.Node
 
setAMQSession(AMQSession) - Method in class org.apache.qpid.client.message.AbstractJMSMessage
The session is set when CLIENT_ACKNOWLEDGE mode is used so that the CHANNEL ACK can be sent when the user calls acknowledge()
setAMQSession(AMQSession) - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
setAMQSession(AMQSession) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
The session is set when CLIENT_ACKNOWLEDGE mode is used so that the CHANNEL ACK can be sent when the user calls acknowledge()
setAMQSession(AMQSession) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
The session is set when CLIENT_ACKNOWLEDGE mode is used so that the CHANNEL ACK can be sent when the user calls acknowledge()
setArgs(Map<String, Object>) - Method in class org.apache.qpid.client.messaging.address.Link.Subscription
 
setAssert(AMQDestination.AddressOption) - Method in class org.apache.qpid.client.AMQDestination
 
setAutoDelete(boolean) - Method in class org.apache.qpid.client.AMQDestination
 
setAutoDelete(boolean) - Method in class org.apache.qpid.client.messaging.address.Node
 
setBindings(List<AMQDestination.Binding>) - Method in class org.apache.qpid.client.messaging.address.Node
 
setBoolean(AMQShortString, boolean) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
setBoolean(String, boolean) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
setBoolean(String, boolean) - Method in class org.apache.qpid.client.message.JMSMapMessage
 
setBooleanProperty(String, boolean) - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
setBooleanProperty(String, boolean) - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
setBooleanProperty(String, boolean) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
setBooleanProperty(String, boolean) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
setBroker(BrokerDetails) - Method in class org.apache.qpid.jms.failover.FailoverExchangeMethod
 
setBroker(BrokerDetails) - Method in interface org.apache.qpid.jms.failover.FailoverMethod
Set the currently active broker to be the new value.
setBroker(BrokerDetails) - Method in class org.apache.qpid.jms.failover.FailoverRoundRobinServers
 
setBroker(BrokerDetails) - Method in class org.apache.qpid.jms.failover.FailoverSingleServer
 
setBroker(BrokerDetails) - Method in class org.apache.qpid.jms.FailoverPolicy
 
setBrokerDetails(List<BrokerDetails>) - Method in class org.apache.qpid.client.AMQConnectionURL
 
setBrokerDetails(List<BrokerDetails>) - Method in interface org.apache.qpid.jms.ConnectionURL
 
setBrowseOnly(boolean) - Method in class org.apache.qpid.client.AMQDestination
 
setByte(String, byte) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
setByte(AMQShortString, byte) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
setByte(String, byte) - Method in class org.apache.qpid.client.message.JMSMapMessage
 
setByteProperty(String, byte) - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
setByteProperty(String, byte) - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
setByteProperty(String, byte) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
setByteProperty(String, byte) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
setBytes(AMQShortString, byte[]) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
setBytes(String, byte[]) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
setBytes(String, byte[], int, int) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
setBytes(String, byte[]) - Method in class org.apache.qpid.client.message.JMSMapMessage
 
setBytes(String, byte[], int, int) - Method in class org.apache.qpid.client.message.JMSMapMessage
 
setCertType(String) - Method in class org.apache.qpid.client.SSLConfiguration
 
setChannelMax(int) - Method in class org.apache.qpid.client.ConnectionTuneParameters
 
setChar(String, char) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
setChar(String, char) - Method in class org.apache.qpid.client.message.JMSMapMessage
 
setCheckedForQueueBinding(boolean) - Method in class org.apache.qpid.client.AMQDestination
 
setClientID(String) - Method in class org.apache.qpid.client.AMQConnection
 
setClientID(String) - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
 
setClientName(String) - Method in class org.apache.qpid.client.AMQConnectionURL
 
setClientName(String) - Method in interface org.apache.qpid.jms.ConnectionURL
 
setConnectionListener(ConnectionListener) - Method in class org.apache.qpid.client.AMQConnection
 
setConnectionListener(ConnectionListener) - Method in interface org.apache.qpid.jms.Connection
 
setConnectionPrefix(String) - Method in class org.apache.qpid.jndi.PropertiesFileInitialContextFactory
 
setConnectionStopped(boolean) - Method in class org.apache.qpid.client.AMQSession.Dispatcher
 
setConnectionTuneParameters(ConnectionTuneParameters) - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
 
setConnectionURLString(String) - Method in class org.apache.qpid.client.AMQConnectionFactory
 
setConsumerCapacity(int) - Method in class org.apache.qpid.client.messaging.address.Link
 
setConsumerTag(int) - Method in class org.apache.qpid.client.BasicMessageConsumer
 
setConsumerTag(int) - Method in class org.apache.qpid.client.BasicMessageConsumer_0_10
 
setContentHeader(ContentHeaderBody) - Method in class org.apache.qpid.client.message.UnprocessedMessage_0_8
 
setContentType(String) - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
setContentType(String) - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
setContentType(String) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
setContentType(String) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
setCreate(AMQDestination.AddressOption) - Method in class org.apache.qpid.client.AMQDestination
 
setCurrentException(SessionException) - Method in class org.apache.qpid.client.AMQSession_0_10
 
setDebugStream(PrintStream) - Method in class org.apache.qpid.filter.selector.SelectorParserTokenManager
Set debug output.
setDeclareArgs(Map<String, Object>) - Method in class org.apache.qpid.client.messaging.address.Node
 
setDefaultConfig(SocketConnectorConfig) - Method in class org.apache.mina.transport.socket.nio.ExistingSocketConnector
Sets the config this connector will use by default.
setDefaultPassword(String) - Method in class org.apache.qpid.client.AMQConnectionFactory
 
setDefaultQueueExchangeName(AMQShortString) - Method in class org.apache.qpid.client.AMQConnection
 
setDefaultQueueExchangeName(AMQShortString) - Method in class org.apache.qpid.client.AMQConnectionURL
 
setDefaultTopicExchangeName(AMQShortString) - Method in class org.apache.qpid.client.AMQConnection
 
setDefaultTopicExchangeName(AMQShortString) - Method in class org.apache.qpid.client.AMQConnectionURL
 
setDefaultUsername(String) - Method in class org.apache.qpid.client.AMQConnectionFactory
 
setDelete(AMQDestination.AddressOption) - Method in class org.apache.qpid.client.AMQDestination
 
setDeliveryMode(int) - Method in class org.apache.qpid.client.BasicMessageProducer
 
setDeliveryMode(int) - Method in class org.apache.qpid.client.QueueSenderAdapter
 
setDeliveryMode(int) - Method in class org.apache.qpid.client.TopicPublisherAdapter
 
setDeliveryProperties(DeliveryProperties) - Method in class org.apache.qpid.nclient.util.ByteBufferMessage
 
setDestinationPrefix(String) - Method in class org.apache.qpid.jndi.PropertiesFileInitialContextFactory
 
setDestSyntax(AMQDestination.DestSyntax) - Method in class org.apache.qpid.client.AMQDestination
 
setDestType(int) - Method in class org.apache.qpid.client.message.ExchangeInfo
 
setDisableMessageID(boolean) - Method in class org.apache.qpid.client.BasicMessageProducer
 
setDisableMessageID(boolean) - Method in class org.apache.qpid.client.QueueSenderAdapter
 
setDisableMessageID(boolean) - Method in class org.apache.qpid.client.TopicPublisherAdapter
 
setDisableMessageTimestamp(boolean) - Method in class org.apache.qpid.client.BasicMessageProducer
 
setDisableMessageTimestamp(boolean) - Method in class org.apache.qpid.client.QueueSenderAdapter
 
setDisableMessageTimestamp(boolean) - Method in class org.apache.qpid.client.TopicPublisherAdapter
 
setDouble(String, double) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
setDouble(String, double) - Method in class org.apache.qpid.client.message.JMSMapMessage
 
setDoubleProperty(String, double) - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
setDoubleProperty(String, double) - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
setDoubleProperty(String, double) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
setDoubleProperty(String, double) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
setDurable(boolean) - Method in class org.apache.qpid.client.AMQDestination
 
setDurable(boolean) - Method in class org.apache.qpid.client.messaging.address.Link
 
setDurable(boolean) - Method in class org.apache.qpid.client.messaging.address.Node
 
setEncoding(String) - Method in class org.apache.qpid.client.BasicMessageProducer
 
setEncoding(String) - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
setEncoding(String) - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
setEncoding(String) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
setEncoding(String) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
setEncoding(String) - Method in interface org.apache.qpid.jms.MessageProducer
Set the default encoding for messages produced by this producer.
setExceptionListener(ExceptionListener) - Method in class org.apache.qpid.client.AMQConnection
 
setExchangeClass(AMQShortString) - Method in class org.apache.qpid.client.AMQDestination
 
setExchangeExistsChecked(boolean) - Method in class org.apache.qpid.client.AMQDestination
 
setExchangeName(AMQShortString) - Method in class org.apache.qpid.client.AMQDestination
 
setExchangeName(String) - Method in class org.apache.qpid.client.message.ExchangeInfo
 
setExchangeType(String) - Method in class org.apache.qpid.client.message.ExchangeInfo
 
setExchangeType(String) - Method in class org.apache.qpid.client.messaging.address.Node.ExchangeNode
 
setExclusive(boolean) - Method in class org.apache.qpid.client.messaging.address.Link.Subscription
 
setExclusive(boolean) - Method in class org.apache.qpid.client.messaging.address.Node.QueueNode
 
setExclusiveBinding() - Method in class org.apache.qpid.client.messaging.address.QpidExchangeOptions
 
setFailoverLatch(CountDownLatch) - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
 
setFailoverMethod(String) - Method in class org.apache.qpid.client.AMQConnectionURL
 
setFailoverOption(String, String) - Method in class org.apache.qpid.client.AMQConnectionURL
 
setFailoverPolicy(FailoverPolicy) - Method in class org.apache.qpid.client.AMQConnection
 
setFailoverState(FailoverState) - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
 
setFilter(String) - Method in class org.apache.qpid.client.messaging.address.Link
 
setFilterType(Link.FilterType) - Method in class org.apache.qpid.client.messaging.address.Link
 
setFloat(String, float) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
setFloat(String, float) - Method in class org.apache.qpid.client.message.JMSMapMessage
 
setFloatProperty(String, float) - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
setFloatProperty(String, float) - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
setFloatProperty(String, float) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
setFloatProperty(String, float) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
setFlowControl(boolean) - Method in class org.apache.qpid.client.AMQSession
 
setFlowControl(int, boolean) - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
 
setFrameMax(long) - Method in class org.apache.qpid.client.ConnectionTuneParameters
 
setHasMessageListeners() - Method in class org.apache.qpid.client.AMQSession
 
setHeader(Header) - Method in class org.apache.qpid.nclient.util.ByteBufferMessage
 
setHeartbeat(int) - Method in class org.apache.qpid.client.ConnectionTuneParameters
 
setHost(String) - Method in class org.apache.qpid.client.AMQBrokerDetails
 
setHost(String) - Method in class org.apache.qpid.client.AMQConnectionFactory
 
setHost(String) - Method in class org.apache.qpid.client.failover.FailoverHandler
Sets the host name to fail over to.
setHost(String) - Method in interface org.apache.qpid.jms.BrokerDetails
 
setInitialValueExchange() - Method in class org.apache.qpid.client.messaging.address.QpidExchangeOptions
 
setInRecovery(boolean) - Method in class org.apache.qpid.client.AMQSession
 
setInt(String, int) - Method in class org.apache.qpid.client.message.JMSMapMessage
 
setInteger(String, int) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
setInteger(AMQShortString, int) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
setIntProperty(String, int) - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
setIntProperty(String, int) - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
setIntProperty(String, int) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
setIntProperty(String, int) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
setJMSCorrelationID(String) - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
setJMSCorrelationID(String) - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
setJMSCorrelationID(String) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
setJMSCorrelationID(String) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
setJMSCorrelationIDAsBytes(byte[]) - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
setJMSCorrelationIDAsBytes(byte[]) - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
setJMSCorrelationIDAsBytes(byte[]) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
setJMSCorrelationIDAsBytes(byte[]) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
setJMSDeliveryMode(int) - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
setJMSDeliveryMode(int) - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
setJMSDeliveryMode(int) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
setJMSDeliveryMode(int) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
setJMSDestination(Destination) - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
setJMSDestination(Destination) - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
setJMSDestination(Destination) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
setJMSDestination(Destination) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
setJMSExpiration(long) - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
setJMSExpiration(long) - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
setJMSExpiration(long) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
setJMSExpiration(long) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
setJMSMessageID(String) - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
setJMSMessageID(UUID) - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
setJMSMessageID(String) - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
setJMSMessageID(UUID) - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
setJMSMessageID(String) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
setJMSMessageID(UUID) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
setJMSMessageID(String) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
setJMSMessageID(UUID) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
setJMSPriority(int) - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
setJMSPriority(int) - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
setJMSPriority(int) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
setJMSPriority(int) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
setJMSProperties(Message) - Method in class org.apache.qpid.client.message.MessageConverter
Exposed JMS defined properties on converted message: JMSDestination - we don't set here JMSDeliveryMode - set JMSExpiration - we don't set here JMSPriority - we don't set here JMSMessageID - we don't set here JMSTimestamp - we don't set here JMSCorrelationID - set JMSReplyTo - set JMSType - set JMSRedlivered - we don't set here
setJMSRedelivered(boolean) - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
setJMSReplyTo(Destination) - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
setJMSReplyTo(Destination) - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
setJMSReplyTo(Destination) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
setJMSReplyTo(Destination) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
setJMSTimestamp(long) - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
setJMSTimestamp(long) - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
setJMSTimestamp(long) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
setJMSTimestamp(long) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
setJMSType(String) - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
setJMSType(String) - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
setJMSType(String) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
setJMSType(String) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
setKeystorePassword(String) - Method in class org.apache.qpid.client.SSLConfiguration
 
setKeystorePath(String) - Method in class org.apache.qpid.client.SSLConfiguration
 
setLeft(Expression) - Method in class org.apache.qpid.filter.BinaryExpression
 
setLegacyFiledsForQueueType(AMQDestination) - Method in class org.apache.qpid.client.AMQSession_0_10
 
setLegacyFiledsForTopicType(AMQDestination) - Method in class org.apache.qpid.client.AMQSession_0_10
 
setLink(Link) - Method in class org.apache.qpid.client.AMQDestination
 
setLong(String, long) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
setLong(String, long) - Method in class org.apache.qpid.client.message.JMSMapMessage
 
setLongProperty(String, long) - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
setLongProperty(String, long) - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
setLongProperty(String, long) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
setLongProperty(String, long) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
setLvqKey(String) - Method in class org.apache.qpid.client.messaging.address.QpidQueueOptions
 
setMap(Map<String, Object>) - Method in class org.apache.qpid.client.message.AMQPEncodedMapMessage
 
setMaxChannelID(int) - Method in class org.apache.qpid.client.AMQConnection.ChannelToSessionMap
 
setMaxCount(Integer) - Method in class org.apache.qpid.client.messaging.address.QpidQueueOptions
 
setMaximumChannelCount(long) - Method in class org.apache.qpid.client.AMQConnection
 
setMaximumFrameSize(long) - Method in class org.apache.qpid.client.AMQConnection
 
setMaxSize(Integer) - Method in class org.apache.qpid.client.messaging.address.QpidQueueOptions
 
setMessageListener(MessageListener) - Method in class org.apache.qpid.client.AMQQueueSessionAdaptor
 
setMessageListener(MessageListener) - Method in class org.apache.qpid.client.AMQSession
 
setMessageListener(MessageListener) - Method in class org.apache.qpid.client.AMQTopicSessionAdaptor
 
setMessageListener(MessageListener) - Method in class org.apache.qpid.client.BasicMessageConsumer
 
setMessageListener(MessageListener) - Method in class org.apache.qpid.client.BasicMessageConsumer_0_10
 
setMessageListener(MessageListener) - Method in class org.apache.qpid.client.QueueReceiverAdaptor
 
setMessageListener(MessageListener) - Method in class org.apache.qpid.client.TopicSubscriberAdaptor
 
setMessageProperties(Message) - Method in class org.apache.qpid.client.message.MessageConverter
Sets all message properties
setMessageProperties(MessageProperties) - Method in class org.apache.qpid.nclient.util.ByteBufferMessage
 
setMessageSequencing() - Method in class org.apache.qpid.client.messaging.address.QpidExchangeOptions
 
setMethodBody(BasicDeliverBody) - Method in class org.apache.qpid.client.message.UnprocessedMessage_0_8
 
setMethodDispatcher(MethodDispatcher) - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
 
setMethodRetries(int) - Method in class org.apache.qpid.jms.FailoverPolicy
 
setMimeType(String) - Method in class org.apache.qpid.client.BasicMessageProducer
 
setMimeType(String) - Method in interface org.apache.qpid.jms.MessageProducer
Set the default MIME type for messages produced by this producer.
setName(String) - Method in class org.apache.qpid.client.messaging.address.Link
 
setNetworkDriver(NetworkDriver) - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
 
setNode(Node) - Method in class org.apache.qpid.client.messaging.address.Link
 
setNoLocal(boolean) - Method in class org.apache.qpid.client.messaging.address.Link
 
setNonJMSProperties(Message) - Method in class org.apache.qpid.client.message.MessageConverter
Sets all non-JMS defined properties on converted message
setObject(String, Object) - Method in class org.apache.qpid.client.message.AMQPEncodedMapMessage
 
setObject(String, Object) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
setObject(String, Object) - Method in class org.apache.qpid.client.message.JMSMapMessage
 
setObject(Serializable) - Method in class org.apache.qpid.client.message.JMSObjectMessage
 
setObjectProperty(String, Object) - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
setObjectProperty(String, Object) - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
setObjectProperty(String, Object) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
setObjectProperty(String, Object) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
setOpenSocket(Socket) - Method in class org.apache.mina.transport.socket.nio.ExistingSocketConnector
 
setOption(String, String) - Method in class org.apache.qpid.client.AMQConnectionURL
 
setOption(String, String) - Method in interface org.apache.qpid.jms.ConnectionURL
 
setOrderingPolicy(String) - Method in class org.apache.qpid.client.messaging.address.QpidQueueOptions
 
setOutputFrequencyInMillis(long) - Method in class org.apache.qpid.client.protocol.ProtocolBufferMonitorFilter
 
setPassword(String) - Method in class org.apache.qpid.client.AMQConnectionURL
 
setPassword(String) - Method in interface org.apache.qpid.jms.ConnectionURL
 
setPersistLastNode() - Method in class org.apache.qpid.client.messaging.address.QpidQueueOptions
 
setPolicyType(String) - Method in class org.apache.qpid.client.messaging.address.QpidQueueOptions
 
setPort(int) - Method in class org.apache.qpid.client.AMQBrokerDetails
 
setPort(int) - Method in class org.apache.qpid.client.AMQConnectionFactory
 
setPort(int) - Method in class org.apache.qpid.client.failover.FailoverHandler
Sets the port to fail over to.
setPort(int) - Method in interface org.apache.qpid.jms.BrokerDetails
 
setPrefetchLimits(int, long) - Method in class org.apache.qpid.client.AMQSession_0_8
 
setPriority(int) - Method in class org.apache.qpid.client.BasicMessageProducer
 
setPriority(int) - Method in class org.apache.qpid.client.QueueSenderAdapter
 
setPriority(int) - Method in class org.apache.qpid.client.TopicPublisherAdapter
 
setProducerCapacity(int) - Method in class org.apache.qpid.client.messaging.address.Link
 
setProperties(Map<String, String>) - Method in class org.apache.qpid.client.AMQBrokerDetails
 
setProperties(Map<String, String>) - Method in interface org.apache.qpid.jms.BrokerDetails
Sets the properties associated with this connection
setProperty(String, String) - Method in class org.apache.qpid.client.AMQBrokerDetails
 
setProperty(String, String) - Method in interface org.apache.qpid.jms.BrokerDetails
 
setProtocolSession(AMQProtocolSession) - Method in class org.apache.qpid.client.state.AMQStateManager
Setting of the ProtocolSession will be required when Failover has been successfuly compeleted.
setProtocolVersion(ProtocolVersion) - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
 
setPublishMode() - Method in class org.apache.qpid.client.BasicMessageProducer
 
setQueueEvents(String) - Method in class org.apache.qpid.client.messaging.address.QpidQueueOptions
 
setQueueName(AMQShortString) - Method in class org.apache.qpid.client.AMQDestination
 
setQueueName(String) - Method in class org.apache.qpid.client.AMQTopic
Override since the queue is always private and we must ensure it remains null.
setQueuename(AMQShortString) - Method in class org.apache.qpid.client.BasicMessageConsumer
 
setQueuePrefix(String) - Method in class org.apache.qpid.jndi.PropertiesFileInitialContextFactory
 
setRetries(int) - Method in class org.apache.qpid.jms.failover.FailoverExchangeMethod
 
setRetries(int) - Method in interface org.apache.qpid.jms.failover.FailoverMethod
Set the retries for this method
setRetries(int) - Method in class org.apache.qpid.jms.failover.FailoverRoundRobinServers
 
setRetries(int) - Method in class org.apache.qpid.jms.failover.FailoverSingleServer
 
setRight(Expression) - Method in class org.apache.qpid.filter.BinaryExpression
 
setRight(Expression) - Method in class org.apache.qpid.filter.UnaryExpression
 
setRoutingKey(AMQShortString) - Method in class org.apache.qpid.client.AMQDestination
 
setSaslClient(SaslClient) - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
Store the SASL client currently being used for the authentication handshake
setSender(Sender<ByteBuffer>) - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
 
setShort(String, short) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
setShort(String, short) - Method in class org.apache.qpid.client.message.JMSMapMessage
 
setShortProperty(String, short) - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
setShortProperty(String, short) - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
setShortProperty(String, short) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
setShortProperty(String, short) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
setSourceNode(Node) - Method in class org.apache.qpid.client.AMQDestination
 
setSSLConfiguration(SSLConfiguration) - Method in class org.apache.qpid.client.AMQBrokerDetails
 
setSSLConfiguration(SSLConfiguration) - Method in class org.apache.qpid.client.AMQConnectionFactory
Setter for SSLConfiguration
setSSLConfiguration(SSLConfiguration) - Method in interface org.apache.qpid.jms.BrokerDetails
 
setStateManager(AMQStateManager) - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
 
setString(String, String) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
setString(AMQShortString, String) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
setString(String, String) - Method in class org.apache.qpid.client.message.JMSMapMessage
 
setStringProperty(String, String) - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
setStringProperty(String, String) - Method in interface org.apache.qpid.client.message.AMQMessageDelegate
 
setStringProperty(String, String) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
 
setStringProperty(String, String) - Method in class org.apache.qpid.client.message.AMQMessageDelegate_0_8
 
setSubject(String) - Method in class org.apache.qpid.client.AMQDestination
 
setSubscription(Link.Subscription) - Method in class org.apache.qpid.client.messaging.address.Link
 
setTabSize(int) - Method in class org.apache.qpid.filter.selector.SimpleCharStream
 
setTargetNode(Node) - Method in class org.apache.qpid.client.AMQDestination
 
setTemporaryQueueExchangeName(AMQShortString) - Method in class org.apache.qpid.client.AMQConnection
 
setTemporaryQueueExchangeName(AMQShortString) - Method in class org.apache.qpid.client.AMQConnectionURL
 
setTemporaryTopicExchangeName(AMQShortString) - Method in class org.apache.qpid.client.AMQConnection
 
setTemporaryTopicExchangeName(AMQShortString) - Method in class org.apache.qpid.client.AMQConnectionURL
 
setText(String) - Method in class org.apache.qpid.client.message.JMSTextMessage
 
setThreshold(int) - Method in class org.apache.qpid.client.protocol.ProtocolBufferMonitorFilter
 
setTicket(int) - Method in class org.apache.qpid.client.AMQSession
 
setTicket(int, int) - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
 
setTimeout(long) - Method in class org.apache.qpid.client.AMQBrokerDetails
 
setTimeout(long) - Method in interface org.apache.qpid.jms.BrokerDetails
 
setTimeToLive(long) - Method in class org.apache.qpid.client.BasicMessageProducer
 
setTimeToLive(long) - Method in class org.apache.qpid.client.QueueSenderAdapter
 
setTimeToLive(long) - Method in class org.apache.qpid.client.TopicPublisherAdapter
 
setTopicPrefix(String) - Method in class org.apache.qpid.jndi.PropertiesFileInitialContextFactory
 
setTransactionTimeout(int) - Method in class org.apache.qpid.client.XAResourceImpl
Sets the current transaction timeout value for this XAResource instance.
setTransport(String) - Method in class org.apache.qpid.client.AMQBrokerDetails
 
setTransport(String) - Method in interface org.apache.qpid.jms.BrokerDetails
 
setTxnLimit(long) - Method in class org.apache.qpid.client.ConnectionTuneParameters
 
setUsername(String) - Method in class org.apache.qpid.client.AMQConnection
 
setUsername(String) - Method in class org.apache.qpid.client.AMQConnectionURL
 
setUsername(String) - Method in interface org.apache.qpid.jms.ConnectionURL
 
setValue(Object) - Method in class org.apache.qpid.collections.keyvalue.AbstractMapEntry
Sets the value stored in this Map.Entry.
setVirtualHost(String) - Method in class org.apache.qpid.client.AMQConnectionURL
 
setVirtualHost(String) - Method in interface org.apache.qpid.jms.ConnectionURL
 
setVirtualPath(String) - Method in class org.apache.qpid.client.AMQConnectionFactory
 
setWorkerTimeout(int) - Method in class org.apache.mina.transport.socket.nio.ExistingSocketConnector
Set how many seconds the connection worker thread should remain alive once idle before terminating itself.
SHORT_TYPE - Static variable in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
SimpleCharStream - Class in org.apache.qpid.filter.selector
An implementation of interface CharStream, where the stream is assumed to contain only ASCII characters (without unicode processing).
SimpleCharStream(Reader, int, int, int) - Constructor for class org.apache.qpid.filter.selector.SimpleCharStream
Constructor.
SimpleCharStream(Reader, int, int) - Constructor for class org.apache.qpid.filter.selector.SimpleCharStream
Constructor.
SimpleCharStream(Reader) - Constructor for class org.apache.qpid.filter.selector.SimpleCharStream
Constructor.
SimpleCharStream(InputStream, String, int, int, int) - Constructor for class org.apache.qpid.filter.selector.SimpleCharStream
Constructor.
SimpleCharStream(InputStream, int, int, int) - Constructor for class org.apache.qpid.filter.selector.SimpleCharStream
Constructor.
SimpleCharStream(InputStream, String, int, int) - Constructor for class org.apache.qpid.filter.selector.SimpleCharStream
Constructor.
SimpleCharStream(InputStream, int, int) - Constructor for class org.apache.qpid.filter.selector.SimpleCharStream
Constructor.
SimpleCharStream(InputStream, String) - Constructor for class org.apache.qpid.filter.selector.SimpleCharStream
Constructor.
SimpleCharStream(InputStream) - Constructor for class org.apache.qpid.filter.selector.SimpleCharStream
Constructor.
SINGLE_BROKER - Static variable in interface org.apache.qpid.jms.failover.FailoverMethod
 
size() - Method in class org.apache.qpid.client.AMQConnection.ChannelToSessionMap
 
size() - Method in class org.apache.qpid.collections.ReferenceMap
Deprecated. Returns the size of this map.
SOCKET - Static variable in interface org.apache.qpid.jms.BrokerDetails
 
SocketTransportConnection - Class in org.apache.qpid.client.transport
 
SocketTransportConnection(SocketTransportConnection.SocketConnectorFactory) - Constructor for class org.apache.qpid.client.transport.SocketTransportConnection
 
SocketTransportConnection.SocketConnectorFactory - Interface in org.apache.qpid.client.transport
 
SOFT - Static variable in class org.apache.qpid.collections.ReferenceMap
Deprecated. Constant indicating that soft references should be used.
specialToken - Variable in class org.apache.qpid.filter.selector.Token
This field is used to access special tokens that occur prior to this token, but after the immediately preceding regular (non-special) token.
SpecificMethodFrameListener - Class in org.apache.qpid.client.state.listener
 
SpecificMethodFrameListener(int, Class) - Constructor for class org.apache.qpid.client.state.listener.SpecificMethodFrameListener
 
SSLConfiguration - Class in org.apache.qpid.client
 
SSLConfiguration() - Constructor for class org.apache.qpid.client.SSLConfiguration
 
start() - Method in class org.apache.qpid.client.AMQConnection
Start the connection, i.e.
start() - Method in class org.apache.qpid.client.AMQSession
Starts the session, which ensures that it is not suspended and that its event dispatcher is running.
start(Xid, int) - Method in class org.apache.qpid.client.XAResourceImpl
Starts work on behalf of a transaction branch specified in xid.
startDispatcherIfNecessary() - Method in class org.apache.qpid.client.AMQSession
 
startDispatcherIfNecessary(boolean) - Method in class org.apache.qpid.client.AMQSession
 
started() - Method in class org.apache.qpid.client.AMQConnection
 
StateAwareMethodListener<B extends org.apache.qpid.framing.AMQMethodBody> - Interface in org.apache.qpid.client.state
A frame listener that is informed of the protocl state when invoked and has the opportunity to update state.
stateChanged(AMQStateChangedEvent) - Method in interface org.apache.qpid.client.state.AMQStateListener
 
StateWaiter - Class in org.apache.qpid.client.state
This is an implementation of the BlockingWaiter to provide error handing and a waiting mechanism for state changes.
StateWaiter(AMQStateManager, AMQState, Set<AMQState>) - Constructor for class org.apache.qpid.client.state.StateWaiter
 
STATIC_LEXER_ERROR - Static variable in error org.apache.qpid.filter.selector.TokenMgrError
An attempt was made to create a second instance of a static token manager.
staticFlag - Static variable in class org.apache.qpid.filter.selector.SimpleCharStream
Whether parser is static.
stop() - Method in class org.apache.qpid.client.AMQConnection
 
stop() - Method in class org.apache.qpid.client.AMQSession
 
STRICT_AMQP - Static variable in class org.apache.qpid.client.AMQSession
System property to enable strict AMQP compliance.
STRICT_AMQP_DEFAULT - Static variable in class org.apache.qpid.client.AMQSession
Strict AMQP default setting.
STRICT_AMQP_FATAL - Static variable in class org.apache.qpid.client.AMQSession
System property to enable failure if strict AMQP compliance is violated.
STRICT_AMQP_FATAL_DEFAULT - Static variable in class org.apache.qpid.client.AMQSession
Strickt AMQP failure default.
STRING_LITERAL - Static variable in interface org.apache.qpid.filter.selector.SelectorParserConstants
RegularExpression Id.
STRING_TYPE - Static variable in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
stringLitteral() - Method in class org.apache.qpid.filter.selector.SelectorParser
 
stripSyntaxPrefix(String) - Static method in class org.apache.qpid.client.AMQDestination
 
subscription - Variable in class org.apache.qpid.client.messaging.address.Link
 
suspendChannel(boolean) - Method in class org.apache.qpid.client.AMQSession
Suspends or unsuspends this session.
SwitchTo(int) - Method in class org.apache.qpid.filter.selector.SelectorParserTokenManager
Switch to specified lex state.
sync() - Method in class org.apache.qpid.client.AMQSession
 
sync() - Method in class org.apache.qpid.client.AMQSession_0_10
 
sync() - Method in class org.apache.qpid.client.AMQSession_0_8
 
syncDispatchQueue() - Method in class org.apache.qpid.client.AMQSession
 
syncWrite(AMQFrame, Class) - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
More convenient method to write a frame and wait for it's response.
syncWrite(AMQFrame, Class, long) - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
More convenient method to write a frame and wait for it's response.

T

tabSize - Variable in class org.apache.qpid.filter.selector.SimpleCharStream
 
tagLE(long, long) - Method in class org.apache.qpid.client.AMQSession
 
tagLE(long, long) - Method in class org.apache.qpid.client.AMQSession_0_10
 
tagLE(long, long) - Method in class org.apache.qpid.client.AMQSession_0_8
 
take() - Method in class org.apache.qpid.client.util.FlowControllingBlockingQueue
 
TCP - Static variable in interface org.apache.qpid.jms.BrokerDetails
 
TemporaryDestination - Interface in org.apache.qpid.client
Provides support for covenience interface implemented by both AMQTemporaryTopic and AMQTemporaryQueue so that operations related to their "temporary-ness" can be abstracted out.
timeout() - Static method in class org.apache.qpid.client.protocol.HeartbeatDiagnostics
 
toBodyString() - Method in class org.apache.qpid.client.message.AbstractBytesMessage
 
toBodyString() - Method in class org.apache.qpid.client.message.AbstractJMSMessage
Get a String representation of the body of the message.
toBodyString() - Method in class org.apache.qpid.client.message.JMSMapMessage
 
toBodyString() - Method in class org.apache.qpid.client.message.JMSObjectMessage
 
toBodyString() - Method in class org.apache.qpid.client.message.JMSTextMessage
 
toByteEncoding() - Method in class org.apache.qpid.client.AMQDestination
 
token - Variable in class org.apache.qpid.filter.selector.SelectorParser
Current token.
Token - Class in org.apache.qpid.filter.selector
Describes the input token stream.
Token() - Constructor for class org.apache.qpid.filter.selector.Token
No-argument constructor
Token(int) - Constructor for class org.apache.qpid.filter.selector.Token
Constructs a new token for the specified Image.
Token(int, String) - Constructor for class org.apache.qpid.filter.selector.Token
Constructs a new token for the specified Image and Kind.
token_source - Variable in class org.apache.qpid.filter.selector.SelectorParser
Generated Token Manager.
tokenBegin - Variable in class org.apache.qpid.filter.selector.SimpleCharStream
 
tokenImage - Variable in exception org.apache.qpid.filter.selector.ParseException
This is a reference to the "tokenImage" array of the generated parser within which the parse error occurred.
tokenImage - Static variable in interface org.apache.qpid.filter.selector.SelectorParserConstants
Literal token values.
TokenMgrError - Error in org.apache.qpid.filter.selector
Token Manager Error.
TokenMgrError() - Constructor for error org.apache.qpid.filter.selector.TokenMgrError
No arg constructor.
TokenMgrError(String, int) - Constructor for error org.apache.qpid.filter.selector.TokenMgrError
Constructor with message and reason.
TokenMgrError(boolean, int, int, int, String, char, int) - Constructor for error org.apache.qpid.filter.selector.TokenMgrError
Full Constructor.
TOPIC_TYPE - Static variable in class org.apache.qpid.client.AMQDestination
 
TopicPublisherAdapter - Class in org.apache.qpid.client
 
TopicPublisherAdapter(BasicMessageProducer, Topic) - Constructor for class org.apache.qpid.client.TopicPublisherAdapter
 
TopicSubscriber - Interface in org.apache.qpid.jms
 
TopicSubscriberAdaptor<C extends BasicMessageConsumer> - Class in org.apache.qpid.client
Wraps a MessageConsumer to fulfill the extended TopicSubscriber contract
TopicSubscriberAdaptor(Topic, C, boolean) - Constructor for class org.apache.qpid.client.TopicSubscriberAdaptor
 
TopicSubscriberAdaptor(Topic, C) - Constructor for class org.apache.qpid.client.TopicSubscriberAdaptor
 
toString() - Method in class org.apache.qpid.client.AMQBrokerDetails
 
toString() - Method in class org.apache.qpid.client.AMQConnection
 
toString() - Method in class org.apache.qpid.client.AMQConnectionURL
 
toString() - Method in class org.apache.qpid.client.AMQDestination
 
toString() - Method in class org.apache.qpid.client.failover.FailoverState
Prints this state, mainly for debugging purposes.
toString() - Method in class org.apache.qpid.client.message.AbstractJMSMessage
 
toString() - Method in class org.apache.qpid.client.message.UnprocessedMessage_0_8
 
toString() - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
 
toString() - Method in enum org.apache.qpid.client.state.AMQState
 
toString() - Method in exception org.apache.qpid.client.transport.AMQNoTransportForProtocolException
 
toString() - Method in exception org.apache.qpid.client.vmbroker.AMQVMBrokerCreationException
 
toString() - Method in class org.apache.qpid.collections.keyvalue.AbstractKeyValue
Gets a debugging String view of the pair.
toString() - Method in class org.apache.qpid.filter.BinaryExpression
 
toString() - Method in class org.apache.qpid.filter.ConstantExpression
 
toString() - Method in class org.apache.qpid.filter.PropertyExpression
 
toString() - Method in class org.apache.qpid.filter.selector.Token
Returns the image.
toString() - Method in class org.apache.qpid.filter.UnaryExpression
 
toString() - Method in interface org.apache.qpid.jms.BrokerDetails
 
toString() - Method in class org.apache.qpid.jms.failover.FailoverExchangeMethod
 
toString() - Method in class org.apache.qpid.jms.failover.FailoverRoundRobinServers
 
toString() - Method in class org.apache.qpid.jms.failover.FailoverSingleServer
 
toString() - Method in class org.apache.qpid.jms.failover.NoFailover
 
toString() - Method in class org.apache.qpid.jms.FailoverPolicy
 
toString() - Method in class org.apache.qpid.nclient.util.ByteBufferMessage
 
toURL() - Method in class org.apache.qpid.client.AMQConnection
 
toURL() - Method in class org.apache.qpid.client.AMQDestination
 
TransportConnection - Class in org.apache.qpid.client.transport
The TransportConnection is a helper class responsible for connecting to an AMQ server.
TransportConnection() - Constructor for class org.apache.qpid.client.transport.TransportConnection
 
treeBindings - Variable in class org.apache.qpid.jndi.ReadOnlyContext
 
treeBindings - Variable in class org.apache.qpid.naming.ReadOnlyContext
 
TRUE - Static variable in class org.apache.qpid.filter.ConstantExpression
 
TRUE - Static variable in interface org.apache.qpid.filter.selector.SelectorParserConstants
RegularExpression Id.
TYPE - Static variable in class org.apache.qpid.client.messaging.address.AddressHelper
 

U

unaryExpr() - Method in class org.apache.qpid.filter.selector.SelectorParser
 
UnaryExpression - Class in org.apache.qpid.filter
An expression which performs an operation on two expression values
UnaryExpression(Expression) - Constructor for class org.apache.qpid.filter.UnaryExpression
 
UnaryExpression.BooleanUnaryExpression - Class in org.apache.qpid.filter
 
UnaryExpression.BooleanUnaryExpression(Expression) - Constructor for class org.apache.qpid.filter.UnaryExpression.BooleanUnaryExpression
 
unbind(Name) - Method in class org.apache.qpid.jndi.ReadOnlyContext
 
unbind(String) - Method in class org.apache.qpid.jndi.ReadOnlyContext
 
unbind(Name) - Method in class org.apache.qpid.naming.ReadOnlyContext
 
unbind(String) - Method in class org.apache.qpid.naming.ReadOnlyContext
 
underThreshold(int) - Method in interface org.apache.qpid.client.util.FlowControllingBlockingQueue.ThresholdListener
 
UNKNOWN_TYPE - Static variable in class org.apache.qpid.client.AMQDestination
 
UnprocessedMessage - Class in org.apache.qpid.client.message
This class contains everything needed to process a JMS message.
UnprocessedMessage(int) - Constructor for class org.apache.qpid.client.message.UnprocessedMessage
 
UnprocessedMessage_0_10 - Class in org.apache.qpid.client.message
This class contains everything needed to process a JMS message.
UnprocessedMessage_0_10(MessageTransfer) - Constructor for class org.apache.qpid.client.message.UnprocessedMessage_0_10
 
UnprocessedMessage_0_8 - Class in org.apache.qpid.client.message
This class contains everything needed to process a JMS message.
UnprocessedMessage_0_8(long, int, AMQShortString, AMQShortString, boolean) - Constructor for class org.apache.qpid.client.message.UnprocessedMessage_0_8
 
unprocessedMessageReceived(int, UnprocessedMessage) - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
Callback invoked from the BasicDeliverMethodHandler when a message has been received.
unsubscribe(String) - Method in class org.apache.qpid.client.AMQQueueSessionAdaptor
 
unsubscribe(String) - Method in class org.apache.qpid.client.AMQSession
 
unsubscribe(String) - Method in class org.apache.qpid.client.AMQTopicSessionAdaptor
 
unwrap(byte[], int, int) - Method in class org.apache.qpid.client.security.amqplain.AmqPlainSaslClient
 
updateExchangeType(String, String) - Static method in class org.apache.qpid.client.message.AbstractAMQMessageDelegate
Update the exchange name to type mapping.
updateExchangeTypeMapping(Header, Session) - Static method in class org.apache.qpid.client.message.AMQMessageDelegate_0_10
Use the 0-10 ExchangeQuery call to validate the exchange type.
UpdateLineColumn(char) - Method in class org.apache.qpid.filter.selector.SimpleCharStream
 
updateRollbackMark(long, long) - Method in class org.apache.qpid.client.AMQSession
 
updateRollbackMark(long, long) - Method in class org.apache.qpid.client.AMQSession_0_10
 
updateRollbackMark(long, long) - Method in class org.apache.qpid.client.AMQSession_0_8
 
URL_0_10 - Static variable in interface org.apache.qpid.jms.ConnectionURL
 
URL_0_8 - Static variable in interface org.apache.qpid.jms.ConnectionURL
 
URL_FORMAT_EXAMPLE - Static variable in interface org.apache.qpid.jms.BrokerDetails
 
URLParser - Class in org.apache.qpid.client.url
 
URLParser(AMQConnectionURL) - Constructor for class org.apache.qpid.client.url.URLParser
 
URLParser_0_10 - Class in org.apache.qpid.client.url
The format Qpid URL is based on the AMQP one.
URLParser_0_10(String) - Constructor for class org.apache.qpid.client.url.URLParser_0_10
 
URLParser_0_10.URLParserState - Enum in org.apache.qpid.client.url
 
USE_AMQP_ENCODED_MAP_MESSAGE - Variable in class org.apache.qpid.client.AMQSession
 
USE_SSL_DEFAULT - Static variable in interface org.apache.qpid.jms.BrokerDetails
 
USERNAME - Static variable in interface org.apache.qpid.jms.BrokerDetails
 
UsernameHashedPasswordCallbackHandler - Class in org.apache.qpid.client.security
 
UsernameHashedPasswordCallbackHandler() - Constructor for class org.apache.qpid.client.security.UsernameHashedPasswordCallbackHandler
 
UsernamePasswordCallbackHandler - Class in org.apache.qpid.client.security
 
UsernamePasswordCallbackHandler() - Constructor for class org.apache.qpid.client.security.UsernamePasswordCallbackHandler
 

V

validatePolicyType(String) - Method in class org.apache.qpid.client.messaging.address.QpidQueueOptions
 
value - Variable in class org.apache.qpid.collections.keyvalue.AbstractKeyValue
The value
valueOf(String) - Static method in enum org.apache.qpid.client.AMQDestination.AddressOption
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.qpid.client.AMQDestination.DestSyntax
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.qpid.client.BasicMessageProducer.PublishMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.qpid.client.CustomJMSXProperty
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.qpid.client.messaging.address.Link.FilterType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.qpid.client.state.AMQState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.qpid.client.url.URLParser_0_10.URLParserState
Returns the enum constant of this type with the specified name.
values() - Method in class org.apache.qpid.client.AMQConnection.ChannelToSessionMap
 
values() - Static method in enum org.apache.qpid.client.AMQDestination.AddressOption
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.qpid.client.AMQDestination.DestSyntax
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.qpid.client.AMQSession.IdToConsumerMap
 
values() - Static method in enum org.apache.qpid.client.BasicMessageProducer.PublishMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.qpid.client.CustomJMSXProperty
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.qpid.client.messaging.address.Link.FilterType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.qpid.client.state.AMQState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.qpid.client.url.URLParser_0_10.URLParserState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.qpid.collections.ReferenceMap
Deprecated. Returns a collection view of this map's values.
variable() - Method in class org.apache.qpid.filter.selector.SelectorParser
 
VIRTUAL_HOST - Static variable in interface org.apache.qpid.jms.BrokerDetails
 
VM - Static variable in interface org.apache.qpid.jms.BrokerDetails
 
VmPipeTransportConnection - Class in org.apache.qpid.client.transport
 
VmPipeTransportConnection(int) - Constructor for class org.apache.qpid.client.transport.VmPipeTransportConnection
 

W

WEAK - Static variable in class org.apache.qpid.collections.ReferenceMap
Deprecated. Constant indicating that weak references should be used.
whilePaused(Queue<MessageConsumerPair>) - Method in class org.apache.qpid.client.DispatcherCallback
 
wrap(byte[], int, int) - Method in class org.apache.qpid.client.security.amqplain.AmqPlainSaslClient
 
writeBoolean(boolean) - Method in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
writeBoolean(boolean) - Method in class org.apache.qpid.client.message.JMSBytesMessage
 
writeBoolean(boolean) - Method in class org.apache.qpid.client.message.JMSStreamMessage
 
writeByte(byte) - Method in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
writeByte(byte) - Method in class org.apache.qpid.client.message.JMSBytesMessage
 
writeByte(byte) - Method in class org.apache.qpid.client.message.JMSStreamMessage
 
writeBytes(byte[]) - Method in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
writeBytes(byte[], int, int) - Method in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
writeBytes(byte[]) - Method in class org.apache.qpid.client.message.JMSBytesMessage
 
writeBytes(byte[], int, int) - Method in class org.apache.qpid.client.message.JMSBytesMessage
 
writeBytes(byte[]) - Method in class org.apache.qpid.client.message.JMSStreamMessage
 
writeBytes(byte[], int, int) - Method in class org.apache.qpid.client.message.JMSStreamMessage
 
writeChar(char) - Method in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
writeChar(char) - Method in class org.apache.qpid.client.message.JMSBytesMessage
 
writeChar(char) - Method in class org.apache.qpid.client.message.JMSStreamMessage
 
writeCommandFrameAndWaitForReply(AMQFrame, BlockingMethodFrameListener) - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
Convenience method that writes a frame to the protocol session and waits for a particular response.
writeCommandFrameAndWaitForReply(AMQFrame, BlockingMethodFrameListener, long) - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
Convenience method that writes a frame to the protocol session and waits for a particular response.
writeDouble(double) - Method in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
writeDouble(double) - Method in class org.apache.qpid.client.message.JMSBytesMessage
 
writeDouble(double) - Method in class org.apache.qpid.client.message.JMSStreamMessage
 
writeFloat(float) - Method in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
writeFloat(float) - Method in class org.apache.qpid.client.message.JMSBytesMessage
 
writeFloat(float) - Method in class org.apache.qpid.client.message.JMSStreamMessage
 
writeFrame(AMQDataBlock) - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
Convenience method that writes a frame to the protocol session.
writeFrame(AMQDataBlock, boolean) - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
 
writeFrame(AMQDataBlock) - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
Convenience method that writes a frame to the protocol session.
writeFrame(AMQDataBlock, boolean) - Method in class org.apache.qpid.client.protocol.AMQProtocolSession
 
writeInt(int) - Method in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
writeInt(int) - Method in class org.apache.qpid.client.message.JMSBytesMessage
 
writeInt(int) - Method in class org.apache.qpid.client.message.JMSStreamMessage
 
writeIntImpl(int) - Method in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
writeLong(long) - Method in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
writeLong(long) - Method in class org.apache.qpid.client.message.JMSBytesMessage
 
writeLong(long) - Method in class org.apache.qpid.client.message.JMSStreamMessage
 
writeMapToData() - Method in class org.apache.qpid.client.message.AMQPEncodedMapMessage
 
writeMapToData() - Method in class org.apache.qpid.client.message.JMSMapMessage
 
writeObject(Object) - Method in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
writeObject(Object) - Method in class org.apache.qpid.client.message.JMSBytesMessage
 
writeObject(Object) - Method in class org.apache.qpid.client.message.JMSStreamMessage
 
writerIdle() - Method in class org.apache.qpid.client.protocol.AMQProtocolHandler
 
writeShort(short) - Method in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
writeShort(short) - Method in class org.apache.qpid.client.message.JMSBytesMessage
 
writeShort(short) - Method in class org.apache.qpid.client.message.JMSStreamMessage
 
writeString(String) - Method in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
writeString(String) - Method in class org.apache.qpid.client.message.JMSStreamMessage
 
writeStringImpl(String) - Method in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
writeToBuffer(ByteBuffer) - Method in class org.apache.qpid.client.message.JMSHeaderAdapter
 
writeTypeDiscriminator(byte) - Method in class org.apache.qpid.client.message.AbstractBytesTypedMessage
 
writeUTF(String) - Method in class org.apache.qpid.client.message.JMSBytesMessage
 

X

X_BINDINGS - Static variable in class org.apache.qpid.client.messaging.address.AddressHelper
 
X_DECLARE - Static variable in class org.apache.qpid.client.messaging.address.AddressHelper
 
X_SUBSCRIBE - Static variable in class org.apache.qpid.client.messaging.address.AddressHelper
 
XAConnectionImpl - Class in org.apache.qpid.client
This class implements the javax.njms.XAConnection interface
XAConnectionImpl(ConnectionURL, SSLConfiguration) - Constructor for class org.apache.qpid.client.XAConnectionImpl
Create a XAConnection from a connectionURL
XAResourceImpl - Class in org.apache.qpid.client
This is an implementation of javax.njms.XAResource.
XAResourceImpl(XASessionImpl) - Constructor for class org.apache.qpid.client.XAResourceImpl
Create an XAResource associated with a XASession
XASessionImpl - Class in org.apache.qpid.client
This is an implementation of the javax.njms.XASEssion interface.
XASessionImpl(Connection, AMQConnection, int, int, int) - Constructor for class org.apache.qpid.client.XASessionImpl
Create a JMS XASession

_

_acknowledgeMode - Variable in class org.apache.qpid.client.AMQSession
Holds the sessions acknowledgement mode.
_acknowledgeMode - Variable in class org.apache.qpid.client.BasicMessageConsumer
The acknowledge mode in force for this consumer.
_adaptee - Variable in class org.apache.qpid.nclient.util.MessagePartListenerAdapter
 
_address - Variable in class org.apache.qpid.client.AMQDestination
 
_addressType - Variable in class org.apache.qpid.client.AMQDestination
 
_addrHelper - Variable in class org.apache.qpid.client.AMQDestination
 
_alternateExchange - Variable in class org.apache.qpid.client.messaging.address.Node
 
_assert - Variable in class org.apache.qpid.client.AMQDestination
 
_awaitStates - Variable in class org.apache.qpid.client.state.StateWaiter
 
_bindings - Variable in class org.apache.qpid.client.messaging.address.Node
 
_changedData - Variable in class org.apache.qpid.client.message.AbstractJMSMessage
 
_channelId - Variable in class org.apache.qpid.client.AMQSession
Holds this session unique identifier, used to distinguish it from other sessions.
_channelId - Variable in class org.apache.qpid.client.BasicMessageConsumer
We need to know the channel id when constructing frames
_channelId - Variable in class org.apache.qpid.client.BasicMessageProducer
 
_channelId - Variable in class org.apache.qpid.client.protocol.BlockingMethodFrameListener
Holds the channel id for the channel upon which this listener is waiting for a response.
_channelId2SessionMap - Variable in class org.apache.qpid.client.protocol.AMQProtocolSession
Maps from the channel id to the AMQSession that it represents.
_closed - Variable in class org.apache.qpid.client.Closeable
We use an atomic boolean so that we do not have to synchronized access to this flag.
_closing - Variable in class org.apache.qpid.client.Closeable
Are we in the process of closing.
_closingChannels - Variable in class org.apache.qpid.client.protocol.AMQProtocolSession
 
_connected - Variable in class org.apache.qpid.client.AMQConnection
 
_connection - Variable in class org.apache.qpid.client.AMQSession
The connection to which this session belongs.
_connection - Variable in class org.apache.qpid.client.BasicMessageConsumer
The connection being used by this consumer
_connection - Variable in class org.apache.qpid.client.protocol.AMQProtocolSession
 
_connectionDetails - Variable in class org.apache.qpid.jms.failover.FailoverRoundRobinServers
Array of BrokerDetail used to make connections.
_consumer - Variable in class org.apache.qpid.client.DispatcherCallback
 
_consumer - Variable in class org.apache.qpid.client.MessageConsumerPair
 
_consumer - Variable in class org.apache.qpid.client.QueueReceiverAdaptor
 
_consumerCapacity - Variable in class org.apache.qpid.client.messaging.address.Link
 
_consumers - Variable in class org.apache.qpid.client.AMQSession
Maps from identifying tags to message consumers, in order to pass dispatch incoming messages to the right consumer.
_consumerTag - Variable in class org.apache.qpid.client.BasicMessageConsumer
The consumer tag allows us to close the consumer by sending a jmsCancel method to the broker
_create - Variable in class org.apache.qpid.client.AMQDestination
 
_currentMsg - Variable in class org.apache.qpid.nclient.util.MessagePartListenerAdapter
 
_currentRetries - Variable in class org.apache.qpid.jms.failover.FailoverSingleServer
The current number of attempts made to the server
_data - Variable in class org.apache.qpid.client.message.AbstractJMSMessage
 
_declareArgs - Variable in class org.apache.qpid.client.messaging.address.Node
 
_delegate - Variable in class org.apache.qpid.client.AMQConnection
 
_delegate - Variable in class org.apache.qpid.client.message.AbstractJMSMessage
If the acknowledge mode is CLIENT_ACKNOWLEDGE the session is required
_delete - Variable in class org.apache.qpid.client.AMQDestination
 
_deliveredMessageTags - Variable in class org.apache.qpid.client.AMQSession
All the delivered message tags
_destination - Variable in class org.apache.qpid.client.BasicMessageConsumer
 
_destination - Variable in class org.apache.qpid.client.BasicMessageProducer
The Destination used for this consumer, if specified upon creation.
_destSyntax - Variable in class org.apache.qpid.client.AMQDestination
 
_details - Variable in exception org.apache.qpid.client.transport.AMQNoTransportForProtocolException
 
_disableTimestamps - Variable in class org.apache.qpid.client.BasicMessageProducer
If true, messages will not get a timestamp.
_dispatcher - Variable in class org.apache.qpid.client.AMQSession
Holds the dispatcher thread for this session.
_dispatcherThread - Variable in class org.apache.qpid.client.AMQSession
 
_doneObject - Variable in class org.apache.qpid.client.util.BlockingWaiter
Holds the incomming Object.
_exceptionListener - Variable in class org.apache.qpid.client.AMQConnection
 
_exchangeClass - Variable in class org.apache.qpid.client.AMQDestination
 
_exchangeName - Variable in class org.apache.qpid.client.AMQDestination
 
_exchangeOptions - Variable in class org.apache.qpid.client.messaging.address.Node.ExchangeNode
 
_exchangeType - Variable in class org.apache.qpid.client.messaging.address.Node.ExchangeNode
 
_exclusive - Variable in class org.apache.qpid.client.BasicMessageConsumer
We store the exclusive field in order to be able to reuse it when resubscribing in the event of failover
_failoverPolicy - Variable in class org.apache.qpid.client.AMQConnection
Policy dictating how to failover
_filter - Variable in class org.apache.qpid.client.messaging.address.Link
 
_filterType - Variable in class org.apache.qpid.client.messaging.address.Link
 
_firstDispatcher - Variable in class org.apache.qpid.client.AMQSession
Used to ensure that onlt the first call to start the dispatcher can unsuspend the channel.
_immediatePrefetch - Variable in class org.apache.qpid.client.AMQSession
Used to indicate that the session should start pre-fetching messages as soon as it is started.
_isAutoDelete - Variable in class org.apache.qpid.client.AMQDestination
 
_isAutoDelete - Variable in class org.apache.qpid.client.messaging.address.Node
 
_isDurable - Variable in class org.apache.qpid.client.AMQDestination
 
_isDurable - Variable in class org.apache.qpid.client.messaging.address.Link
 
_isDurable - Variable in class org.apache.qpid.client.messaging.address.Node
 
_isExclusive - Variable in class org.apache.qpid.client.AMQDestination
 
_isExclusive - Variable in class org.apache.qpid.client.messaging.address.Node.QueueNode
 
_isNoLocal - Variable in class org.apache.qpid.client.messaging.address.Link
 
_item - Variable in class org.apache.qpid.client.MessageConsumerPair
 
_link - Variable in class org.apache.qpid.client.AMQDestination
 
_logger - Variable in class org.apache.qpid.client.BasicMessageConsumer_0_10
This class logger
_logger - Variable in class org.apache.qpid.client.BasicMessageConsumer_0_8
 
_logger - Variable in class org.apache.qpid.client.BasicMessageProducer
 
_logger - Variable in class org.apache.qpid.client.message.MessageConverter
Log4J logger
_logger - Variable in class org.apache.qpid.client.message.MessageFactoryRegistry
This class logger
_logger - Static variable in class org.apache.qpid.client.protocol.AMQProtocolSession
 
_logger - Variable in class org.apache.qpid.jndi.PropertiesFileInitialContextFactory
 
_map - Variable in class org.apache.qpid.client.message.JMSMapMessage
 
_maximumChannelCount - Variable in class org.apache.qpid.client.AMQConnection
A channel is roughly analogous to a session.
_messageFactory - Variable in class org.apache.qpid.client.BasicMessageConsumer
 
_messageFactoryRegistry - Variable in class org.apache.qpid.client.AMQSession
Holds the message factory factory for this session.
_messageSelector - Variable in class org.apache.qpid.client.BasicMessageConsumer
 
_name - Variable in class org.apache.qpid.client.AMQDestination
 
_nodeType - Variable in class org.apache.qpid.client.messaging.address.Node
 
_producerCapacity - Variable in class org.apache.qpid.client.messaging.address.Link
 
_protocolHandler - Variable in class org.apache.qpid.client.AMQConnection
The protocol handler dispatches protocol events for this connection.
_protocolHandler - Variable in class org.apache.qpid.client.BasicMessageConsumer
 
_protocolHandler - Variable in class org.apache.qpid.client.BasicMessageProducer
 
_protocolHandler - Variable in class org.apache.qpid.client.protocol.AMQProtocolSession
The handler from which this session was created and which is used to handle protocol events.
_qpidConnection - Variable in class org.apache.qpid.client.AMQConnectionDelegate_0_10
The QpidConeection instance that is mapped with thie JMS connection.
_qpidConnection - Variable in class org.apache.qpid.client.AMQSession_0_10
 
_queue - Variable in class org.apache.qpid.client.AMQSession
Used to hold incoming messages.
_queue - Variable in class org.apache.qpid.client.QueueReceiverAdaptor
 
_queueId - Variable in class org.apache.qpid.client.protocol.AMQProtocolSession
Counter to ensure unique queue names
_queueIdLock - Variable in class org.apache.qpid.client.protocol.AMQProtocolSession
 
_queueOptions - Variable in class org.apache.qpid.client.messaging.address.Node.QueueNode
 
_readableMessage - Variable in class org.apache.qpid.client.message.AbstractJMSMessage
 
_redelivered - Variable in class org.apache.qpid.client.message.UnprocessedMessage_0_8
 
_retries - Variable in class org.apache.qpid.jms.failover.FailoverSingleServer
The number of times to retry connecting to the sever
_reverseSubscriptionMap - Variable in class org.apache.qpid.client.AMQSession
Holds a mapping from message consumers to their identifying names, so that their subscriptions may be looked up in the AMQSession._subscriptions map.
_session - Variable in class org.apache.qpid.client.AMQQueueSessionAdaptor
 
_session - Variable in class org.apache.qpid.client.AMQTopicSessionAdaptor
 
_session - Variable in class org.apache.qpid.client.BasicMessageConsumer
 
_session - Variable in class org.apache.qpid.client.BasicMessageProducer
The session used to create this producer
_session - Variable in class org.apache.qpid.client.handler.ClientMethodDispatcherImpl
 
_sourceNode - Variable in class org.apache.qpid.client.AMQDestination
 
_started - Variable in class org.apache.qpid.client.AMQConnection
Whether this connection is started, i.e.
_strictAMQP - Variable in class org.apache.qpid.client.AMQSession
Indicates that warnings should be generated on violations of the strict AMQP.
_strictAMQPFATAL - Variable in class org.apache.qpid.client.AMQSession
Indicates that runtime exceptions should be generated on vilations of the strict AMQP.
_subject - Variable in class org.apache.qpid.client.AMQDestination
 
_subscriberAccess - Variable in class org.apache.qpid.client.AMQSession
 
_subscriberDetails - Variable in class org.apache.qpid.client.AMQSession
Locks to keep access to subscriber details atomic.
_subscriptions - Variable in class org.apache.qpid.client.AMQSession
Used to reference durable subscribers so that requests for unsubscribe can be handled correctly.
_synchronousQueue - Variable in class org.apache.qpid.client.BasicMessageConsumer
Used in the blocking receive methods to receive a message from the Session thread.
_targetLink - Variable in class org.apache.qpid.client.AMQDestination
 
_targetNode - Variable in class org.apache.qpid.client.AMQDestination
 
_thisSession - Variable in class org.apache.qpid.client.AMQSession
 
_transacted - Variable in class org.apache.qpid.client.AMQSession
Used to indicate whether or not this is a transactional session.
_unacknowledgedMessageTags - Variable in class org.apache.qpid.client.AMQSession
All the not yet acknowledged message tags
_userID - Variable in class org.apache.qpid.client.BasicMessageProducer
 
_waiters - Variable in class org.apache.qpid.client.state.AMQStateManager
 

A B C D E F G H I J K L M N O P Q R S T U V W X _
CRC Card

Licensed to the Apache Software Foundation