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

A

abortTran() - Method in class org.apache.qpid.server.store.MemoryMessageStore
 
abortTran() - Method in interface org.apache.qpid.server.store.MessageStore
 
AbstractExchange - Class in org.apache.qpid.server.exchange
 
AbstractExchange() - Constructor for class org.apache.qpid.server.exchange.AbstractExchange
 
AbstractExchange.ExchangeMBean - Class in org.apache.qpid.server.exchange
Abstract MBean class.
AbstractExchange.ExchangeMBean() - Constructor for class org.apache.qpid.server.exchange.AbstractExchange.ExchangeMBean
 
acknowledgeMessage(long, boolean) - Method in class org.apache.qpid.server.AMQChannel
Acknowledge one or more messages.
add(Object) - Method in class org.apache.qpid.server.util.CircularBuffer
 
addChannel(AMQChannel) - Method in class org.apache.qpid.server.protocol.AMQMinaProtocolSession
 
addChannel(AMQChannel) - Method in interface org.apache.qpid.server.protocol.AMQProtocolSession
Associate a channel with this session.
addContentBodyFrame(ContentBody) - Method in class org.apache.qpid.server.queue.AMQMessage
 
addNotificationListener(NotificationListener, NotificationFilter, Object) - Method in class org.apache.qpid.server.management.AMQManagedObject
 
addStateListener(StateListener) - Method in class org.apache.qpid.server.state.AMQStateManager
 
addUnacknowledgedMessage(AMQMessage, long, String, AMQQueue) - Method in class org.apache.qpid.server.AMQChannel
Add a message to the channel-based list of unacknowledged messages
AMQChannel - Class in org.apache.qpid.server
 
AMQChannel(int, MessageStore, MessageRouter) - Constructor for class org.apache.qpid.server.AMQChannel
 
AMQManagedObject - Class in org.apache.qpid.server.management
This class provides additinal feature of Notification Broadcaster to the DefaultManagedObject.
AMQManagedObject(Class<?>, String) - Constructor for class org.apache.qpid.server.management.AMQManagedObject
 
AMQMessage - Class in org.apache.qpid.server.queue
Combines the information that make up a deliverable message into a more manageable form.
AMQMessage(MessageStore, BasicPublishBody) - Constructor for class org.apache.qpid.server.queue.AMQMessage
 
AMQMessage(MessageStore, BasicPublishBody, boolean) - Constructor for class org.apache.qpid.server.queue.AMQMessage
 
AMQMessage(MessageStore, long, BasicPublishBody, ContentHeaderBody, List<ContentBody>) - Constructor for class org.apache.qpid.server.queue.AMQMessage
 
AMQMessage(MessageStore, BasicPublishBody, ContentHeaderBody, List<ContentBody>) - Constructor for class org.apache.qpid.server.queue.AMQMessage
 
AMQMessage(AMQMessage) - Constructor for class org.apache.qpid.server.queue.AMQMessage
 
AMQMethodEvent<M extends org.apache.qpid.framing.AMQMethodBody> - Class in org.apache.qpid.server.protocol
An event that is passed to AMQMethodListeners describing a particular method.
AMQMethodEvent(int, M) - Constructor for class org.apache.qpid.server.protocol.AMQMethodEvent
 
AMQMethodListener - Interface in org.apache.qpid.server.protocol
Interface that allows classes to register for interest in protocol method frames.
AMQMinaProtocolSession - Class in org.apache.qpid.server.protocol
 
AMQMinaProtocolSession(IoSession, QueueRegistry, ExchangeRegistry, AMQCodecFactory) - Constructor for class org.apache.qpid.server.protocol.AMQMinaProtocolSession
 
AMQMinaProtocolSession(IoSession, QueueRegistry, ExchangeRegistry, AMQCodecFactory, AMQStateManager) - Constructor for class org.apache.qpid.server.protocol.AMQMinaProtocolSession
 
AMQPFastProtocolHandler - Class in org.apache.qpid.server.protocol
The protocol handler handles "protocol events" for all connections.
AMQPFastProtocolHandler(Integer) - Constructor for class org.apache.qpid.server.protocol.AMQPFastProtocolHandler
 
AMQPFastProtocolHandler(QueueRegistry, ExchangeRegistry) - Constructor for class org.apache.qpid.server.protocol.AMQPFastProtocolHandler
 
AMQPFastProtocolHandler(AMQPFastProtocolHandler) - Constructor for class org.apache.qpid.server.protocol.AMQPFastProtocolHandler
 
AmqPlainInitialiser - Class in org.apache.qpid.server.security.auth.amqplain
 
AmqPlainInitialiser() - Constructor for class org.apache.qpid.server.security.auth.amqplain.AmqPlainInitialiser
 
AmqPlainSaslServer - Class in org.apache.qpid.server.security.auth.amqplain
 
AmqPlainSaslServer(CallbackHandler) - Constructor for class org.apache.qpid.server.security.auth.amqplain.AmqPlainSaslServer
 
AmqPlainSaslServerFactory - Class in org.apache.qpid.server.security.auth.amqplain
 
AmqPlainSaslServerFactory() - Constructor for class org.apache.qpid.server.security.auth.amqplain.AmqPlainSaslServerFactory
 
AMQPProtocolProvider - Class in org.apache.qpid.server.protocol
The protocol provide's role is to encapsulate the initialisation of the protocol handler.
AMQPProtocolProvider() - Constructor for class org.apache.qpid.server.protocol.AMQPProtocolProvider
 
AMQProtocolSession - Interface in org.apache.qpid.server.protocol
 
amqpVersionEquals(byte, byte) - Method in class org.apache.qpid.server.protocol.AMQMinaProtocolSession
 
AMQQueue - Class in org.apache.qpid.server.queue
This is an AMQ Queue, and should not be confused with a JMS queue or any other abstraction like that.
AMQQueue(String, boolean, String, boolean, QueueRegistry) - Constructor for class org.apache.qpid.server.queue.AMQQueue
 
AMQQueue(String, boolean, String, boolean, QueueRegistry, SubscriptionFactory) - Constructor for class org.apache.qpid.server.queue.AMQQueue
 
AMQQueue(String, boolean, String, boolean, QueueRegistry, Executor, SubscriptionFactory) - Constructor for class org.apache.qpid.server.queue.AMQQueue
 
AMQQueue(String, boolean, String, boolean, QueueRegistry, Executor) - Constructor for class org.apache.qpid.server.queue.AMQQueue
 
AMQQueue(String, boolean, String, boolean, QueueRegistry, SubscriptionSet, SubscriptionFactory) - Constructor for class org.apache.qpid.server.queue.AMQQueue
 
AMQQueue(String, boolean, String, boolean, QueueRegistry, SubscriptionSet) - Constructor for class org.apache.qpid.server.queue.AMQQueue
 
AMQQueue(String, boolean, String, boolean, QueueRegistry, Executor, SubscriptionSet, SubscriptionFactory) - Constructor for class org.apache.qpid.server.queue.AMQQueue
 
AMQState - Enum in org.apache.qpid.server.state
States used in the AMQ protocol.
AMQStateManager - Class in org.apache.qpid.server.state
The state manager is responsible for managing the state of the protocol session.
AMQStateManager() - Constructor for class org.apache.qpid.server.state.AMQStateManager
 
AMQStateManager(AMQState, boolean) - Constructor for class org.apache.qpid.server.state.AMQStateManager
 
ApplicationRegistry - Class in org.apache.qpid.server.registry
An abstract application registry that provides access to configuration information and handles the construction and caching of configurable objects.
ApplicationRegistry(Configuration) - Constructor for class org.apache.qpid.server.registry.ApplicationRegistry
 
AsyncDeliveryConfig - Class in org.apache.qpid.server.queue
 
AsyncDeliveryConfig() - Constructor for class org.apache.qpid.server.queue.AsyncDeliveryConfig
 
authenticate(SaslServer, byte[]) - Method in interface org.apache.qpid.server.security.auth.AuthenticationManager
 
authenticate(SaslServer, byte[]) - Method in class org.apache.qpid.server.security.auth.NullAuthenticationManager
 
authenticate(SaslServer, byte[]) - Method in class org.apache.qpid.server.security.auth.SASLAuthenticationManager
 
AuthenticationManager - Interface in org.apache.qpid.server.security.auth
 
AuthenticationProviderInitialiser - Interface in org.apache.qpid.server.security.auth
 
AuthenticationResult - Class in org.apache.qpid.server.security.auth
 
AuthenticationResult(byte[], AuthenticationResult.AuthenticationStatus) - Constructor for class org.apache.qpid.server.security.auth.AuthenticationResult
 
AuthenticationResult(AuthenticationResult.AuthenticationStatus) - Constructor for class org.apache.qpid.server.security.auth.AuthenticationResult
 
AuthenticationResult.AuthenticationStatus - Enum in org.apache.qpid.server.security.auth
 
autodelete() - Method in class org.apache.qpid.server.queue.AMQQueue
 
autoRegister - Variable in class org.apache.qpid.server.handler.QueueDeclareHandler
 

B

BasicAckMethodHandler - Class in org.apache.qpid.server.handler
 
BasicCancelMethodHandler - Class in org.apache.qpid.server.handler
 
BasicConsumeMethodHandler - Class in org.apache.qpid.server.handler
 
BasicPublishMethodHandler - Class in org.apache.qpid.server.handler
 
BasicQosHandler - Class in org.apache.qpid.server.handler
 
BasicQosHandler() - Constructor for class org.apache.qpid.server.handler.BasicQosHandler
 
BasicRecoverMethodHandler - Class in org.apache.qpid.server.handler
 
BasicRecoverMethodHandler() - Constructor for class org.apache.qpid.server.handler.BasicRecoverMethodHandler
 
beginTran() - Method in class org.apache.qpid.server.store.MemoryMessageStore
 
beginTran() - Method in interface org.apache.qpid.server.store.MessageStore
 
bind(int, ConnectorConfiguration) - Method in class org.apache.qpid.server.Main
 
bind(String, Exchange) - Method in class org.apache.qpid.server.queue.AMQQueue
 
bindAddress - Variable in class org.apache.qpid.server.transport.ConnectorConfiguration
 

C

cancel(TxnOp) - Method in class org.apache.qpid.server.txn.TxnBuffer
 
challenge - Variable in class org.apache.qpid.server.security.auth.AuthenticationResult
 
changeState(AMQState) - Method in class org.apache.qpid.server.state.AMQStateManager
 
channel - Variable in class org.apache.qpid.server.queue.SubscriptionImpl
 
ChannelCloseHandler - Class in org.apache.qpid.server.handler
 
ChannelCloseOkHandler - Class in org.apache.qpid.server.handler
 
ChannelFlowHandler - Class in org.apache.qpid.server.handler
 
ChannelOpenHandler - Class in org.apache.qpid.server.handler
 
checkDeliveredToConsumer() - Method in class org.apache.qpid.server.queue.AMQMessage
Called to enforce the 'immediate' flag.
checkPersistent() - Method in class org.apache.qpid.server.ack.TxAck
 
checkToken(Object) - Method in class org.apache.qpid.server.queue.AMQMessage
 
CircularBuffer - Class in org.apache.qpid.server.util
 
CircularBuffer(int) - Constructor for class org.apache.qpid.server.util.CircularBuffer
 
clearAllMessages() - Method in class org.apache.qpid.server.queue.ConcurrentDeliveryManager
 
clearQueue() - Method in interface org.apache.qpid.server.queue.ManagedQueue
Clears the queue by deleting all the undelivered messages from the queue.
close(AMQProtocolSession) - Method in class org.apache.qpid.server.AMQChannel
Called from the protocol session to close this channel and clean up.
close() - Method in class org.apache.qpid.server.exchange.AbstractExchange
 
close() - Method in interface org.apache.qpid.server.exchange.Exchange
 
close() - Method in class org.apache.qpid.server.store.MemoryMessageStore
 
close() - Method in interface org.apache.qpid.server.store.MessageStore
Called to close and cleanup any resources used by the message store.
closeChannel(int) - Method in class org.apache.qpid.server.protocol.AMQMinaProtocolSession
Close a specific channel.
closeChannel(int) - Method in interface org.apache.qpid.server.protocol.AMQProtocolSession
Close a specific channel.
closeChannel(int) - Method in interface org.apache.qpid.server.protocol.ManagedConnection
Unsubscribes the consumers and unregisters the channel from managed objects.
closeConnection() - Method in interface org.apache.qpid.server.protocol.ManagedConnection
Closes all the related channels and unregisters this connection from managed objects.
CLOSED - Static variable in class org.apache.qpid.server.transport.ThreadPoolFilter.EventType
 
closeSession() - Method in class org.apache.qpid.server.protocol.AMQMinaProtocolSession
This must be called when the session is _closed in order to free up any resources managed by the session.
closeSession() - Method in interface org.apache.qpid.server.protocol.AMQProtocolSession
This must be called when the session is _closed in order to free up any resources managed by the session.
collect(long, boolean, List<UnacknowledgedMessage>) - Method in interface org.apache.qpid.server.ack.UnacknowledgedMessageMap
 
collect(long, boolean, List<UnacknowledgedMessage>) - Method in class org.apache.qpid.server.ack.UnacknowledgedMessageMapImpl
 
commandLine - Variable in class org.apache.qpid.server.Main
 
commit() - Method in class org.apache.qpid.server.ack.TxAck
 
commit() - Method in class org.apache.qpid.server.AMQChannel
 
commit() - Method in class org.apache.qpid.server.txn.TxnBuffer
 
commit() - Method in interface org.apache.qpid.server.txn.TxnOp
Complete the operation started by prepare.
commitTran() - Method in class org.apache.qpid.server.store.MemoryMessageStore
 
commitTran() - Method in interface org.apache.qpid.server.store.MessageStore
 
commitTransactions() - Method in interface org.apache.qpid.server.ManagedChannel
Commits the transactions if the channel is transactional.
commitTransactions(int) - Method in interface org.apache.qpid.server.protocol.ManagedConnection
Commits the transactions if the channel is transactional.
compressBufferOnQueue - Variable in class org.apache.qpid.server.queue.ConcurrentDeliveryManager
 
ConcurrentDeliveryManager - Class in org.apache.qpid.server.queue
Manages delivery of messages on behalf of a queue
ConcurrentLinkedQueueNoSize<E> - Class in org.apache.qpid.server.util
 
ConcurrentLinkedQueueNoSize() - Constructor for class org.apache.qpid.server.util.ConcurrentLinkedQueueNoSize
 
ConfigurationFileApplicationRegistry - Class in org.apache.qpid.server.registry
 
ConfigurationFileApplicationRegistry(File) - Constructor for class org.apache.qpid.server.registry.ConfigurationFileApplicationRegistry
 
Configurator - Class in org.apache.qpid.server.configuration
This class contains utilities for populating classes automatically from values pulled from configuration files.
Configurator() - Constructor for class org.apache.qpid.server.configuration.Configurator
 
configure(Object) - Static method in class org.apache.qpid.server.configuration.Configurator
Configure a given instance using the application configuration.
configure() - Method in class org.apache.qpid.server.store.MemoryMessageStore
 
configure(String, Configuration) - Method in class org.apache.qpid.server.store.MemoryMessageStore
 
configure(QueueRegistry, String, Configuration) - Method in class org.apache.qpid.server.store.MemoryMessageStore
 
configure(QueueRegistry, String, Configuration) - Method in interface org.apache.qpid.server.store.MessageStore
Called after instantiation in order to configure the message store.
ConnectionCloseMethodHandler - Class in org.apache.qpid.server.handler
 
ConnectionCloseOkMethodHandler - Class in org.apache.qpid.server.handler
 
ConnectionOpenMethodHandler - Class in org.apache.qpid.server.handler
 
ConnectionSecureOkMethodHandler - Class in org.apache.qpid.server.handler
 
ConnectionStartOkMethodHandler - Class in org.apache.qpid.server.handler
 
ConnectionTuneOkMethodHandler - Class in org.apache.qpid.server.handler
 
ConnectionTuneOkMethodHandler() - Constructor for class org.apache.qpid.server.handler.ConnectionTuneOkMethodHandler
 
ConnectorConfiguration - Class in org.apache.qpid.server.transport
 
ConnectorConfiguration() - Constructor for class org.apache.qpid.server.transport.ConnectorConfiguration
 
consolidate() - Method in class org.apache.qpid.server.ack.TxAck
 
consumerTag - Variable in class org.apache.qpid.server.ack.UnacknowledgedMessage
 
consumerTag - Variable in class org.apache.qpid.server.queue.SubscriptionImpl
 
ConsumerTagNotUniqueException - Exception in org.apache.qpid.server
 
ConsumerTagNotUniqueException() - Constructor for exception org.apache.qpid.server.ConsumerTagNotUniqueException
 
containsPersistentChanges() - Method in class org.apache.qpid.server.txn.TxnBuffer
 
CRAMMD5Initialiser - Class in org.apache.qpid.server.security.auth
 
CRAMMD5Initialiser() - Constructor for class org.apache.qpid.server.security.auth.CRAMMD5Initialiser
 
createAcceptor() - Method in class org.apache.qpid.server.transport.ConnectorConfiguration
 
createBinding(String, String) - Method in interface org.apache.qpid.server.exchange.ManagedExchange
Creates new binding with the given queue and binding.
createExchange(String, String, boolean, boolean, int) - Method in class org.apache.qpid.server.exchange.DefaultExchangeFactory
 
createExchange(String, String, boolean, boolean, int) - Method in interface org.apache.qpid.server.exchange.ExchangeFactory
 
createMBean() - Method in class org.apache.qpid.server.exchange.AbstractExchange
Concrete exchanges must implement this method in order to create the managed representation.
createMBean() - Method in class org.apache.qpid.server.exchange.DestNameExchange
 
createMBean() - Method in class org.apache.qpid.server.exchange.DestWildExchange
 
createMBean() - Method in class org.apache.qpid.server.exchange.HeadersExchange
 
createName() - Method in class org.apache.qpid.server.handler.QueueDeclareHandler
 
createNewExchange(String, String, boolean, boolean) - Method in interface org.apache.qpid.server.management.ManagedBroker
Creates a new Exchange.
createQueue(QueueDeclareBody, QueueRegistry, AMQProtocolSession) - Method in class org.apache.qpid.server.handler.QueueDeclareHandler
 
createQueue(String, boolean, String, boolean) - Method in interface org.apache.qpid.server.management.ManagedBroker
Create a new Queue on the Broker server
createQueue(AMQQueue) - Method in class org.apache.qpid.server.store.MemoryMessageStore
 
createQueue(AMQQueue) - Method in interface org.apache.qpid.server.store.MessageStore
 
createQueues() - Method in class org.apache.qpid.server.store.MemoryMessageStore
 
createQueues() - Method in interface org.apache.qpid.server.store.MessageStore
Recreate all queues that were persisted, including re-enqueuing of existing messages
createSaslServer(String, String, String, Map, CallbackHandler) - Method in class org.apache.qpid.server.security.auth.amqplain.AmqPlainSaslServerFactory
 
createSaslServer(String, String) - Method in interface org.apache.qpid.server.security.auth.AuthenticationManager
 
createSaslServer(String, String) - Method in class org.apache.qpid.server.security.auth.NullAuthenticationManager
 
createSaslServer(String, String, String, Map, CallbackHandler) - Method in class org.apache.qpid.server.security.auth.plain.PlainSaslServerFactory
 
createSaslServer(String, String) - Method in class org.apache.qpid.server.security.auth.SASLAuthenticationManager
 
createSession(IoSession, QueueRegistry, ExchangeRegistry, AMQCodecFactory) - Method in class org.apache.qpid.server.protocol.AMQPFastProtocolHandler
Separated into its own, protected, method to allow easier reuse
createSubscription(int, AMQProtocolSession, String, boolean) - Method in interface org.apache.qpid.server.queue.SubscriptionFactory
 
createSubscription(int, AMQProtocolSession, String) - Method in interface org.apache.qpid.server.queue.SubscriptionFactory
 
createSubscription(int, AMQProtocolSession, String, boolean) - Method in class org.apache.qpid.server.queue.SubscriptionImpl.Factory
 
createSubscription(int, AMQProtocolSession, String) - Method in class org.apache.qpid.server.queue.SubscriptionImpl.Factory
 

D

dataBlockReceived(AMQDataBlock) - Method in class org.apache.qpid.server.protocol.AMQMinaProtocolSession
 
dataBlockReceived(AMQDataBlock) - Method in interface org.apache.qpid.server.protocol.AMQProtocolSession
Called when a protocol data block is received
decrementReference() - Method in class org.apache.qpid.server.queue.AMQMessage
Threadsafe.
DEFAULT_APPLICATION_REGISTRY - Static variable in class org.apache.qpid.server.registry.ApplicationRegistry
 
DEFAULT_INSTANCE - Static variable in class org.apache.qpid.server.registry.ApplicationRegistry
 
DEFAULT_KEEP_ALIVE_TIME - Static variable in class org.apache.qpid.server.transport.ThreadPoolFilter
Default keep-alive time of thread pool (1 min).
DEFAULT_MAXIMUM_POOL_SIZE - Static variable in class org.apache.qpid.server.transport.ThreadPoolFilter
Default maximum size of thread pool (2G).
DEFAULT_PORT - Static variable in class org.apache.qpid.server.transport.ConnectorConfiguration
 
DEFAULT_PREFETCH - Static variable in class org.apache.qpid.server.AMQChannel
 
DefaultExchangeFactory - Class in org.apache.qpid.server.exchange
 
DefaultExchangeFactory() - Constructor for class org.apache.qpid.server.exchange.DefaultExchangeFactory
 
DefaultExchangeRegistry - Class in org.apache.qpid.server.exchange
 
DefaultExchangeRegistry(ExchangeFactory) - Constructor for class org.apache.qpid.server.exchange.DefaultExchangeRegistry
 
DefaultManagedObject - Class in org.apache.qpid.server.management
Provides implementation of the boilerplate ManagedObject interface.
DefaultManagedObject(Class<?>, String) - Constructor for class org.apache.qpid.server.management.DefaultManagedObject
 
DefaultQueueRegistry - Class in org.apache.qpid.server.queue
 
DefaultQueueRegistry() - Constructor for class org.apache.qpid.server.queue.DefaultQueueRegistry
 
delay - Variable in class org.apache.qpid.server.protocol.HeartbeatConfig
 
delete(boolean, boolean) - Method in class org.apache.qpid.server.queue.AMQQueue
 
delete() - Method in class org.apache.qpid.server.queue.AMQQueue
 
deleteMessageFromTop() - Method in interface org.apache.qpid.server.queue.ManagedQueue
Deletes the first message from top.
deleteQueue(String) - Method in interface org.apache.qpid.server.management.ManagedBroker
Unregisters the Queue bindings, removes the subscriptions and unregisters from the managed objects.
deliver(AMQMessage) - Method in class org.apache.qpid.server.queue.AMQQueue
 
deliver(String, AMQMessage) - Method in class org.apache.qpid.server.queue.ConcurrentDeliveryManager
 
deliverAsync() - Method in class org.apache.qpid.server.queue.AMQQueue
 
deliverMessage() - Method in class org.apache.qpid.server.jms.JmsConsumer
 
deliveryTag - Variable in class org.apache.qpid.server.ack.UnacknowledgedMessage
 
dequeue(AMQQueue) - Method in class org.apache.qpid.server.queue.AMQMessage
 
dequeueMessage(String, long) - Method in class org.apache.qpid.server.store.MemoryMessageStore
 
dequeueMessage(String, long) - Method in interface org.apache.qpid.server.store.MessageStore
 
deregisterQueue(String, AMQQueue) - Method in class org.apache.qpid.server.exchange.DestNameExchange
 
deregisterQueue(String, AMQQueue) - Method in class org.apache.qpid.server.exchange.DestWildExchange
 
deregisterQueue(String, AMQQueue) - Method in interface org.apache.qpid.server.exchange.Exchange
 
deregisterQueue(String, AMQQueue) - Method in class org.apache.qpid.server.exchange.HeadersExchange
 
DestNameExchange - Class in org.apache.qpid.server.exchange
 
DestNameExchange() - Constructor for class org.apache.qpid.server.exchange.DestNameExchange
 
destroy() - Method in class org.apache.qpid.server.transport.ThreadPoolFilter
 
DestWildExchange - Class in org.apache.qpid.server.exchange
 
DestWildExchange() - Constructor for class org.apache.qpid.server.exchange.DestWildExchange
 
discard() - Method in class org.apache.qpid.server.ack.UnacknowledgedMessage
 
dispose() - Method in class org.apache.qpid.server.security.auth.amqplain.AmqPlainSaslServer
 
dispose() - Method in class org.apache.qpid.server.security.auth.plain.PlainSaslServer
 
DOMAIN - Static variable in interface org.apache.qpid.server.management.ManagedObject
 
dump() - Method in class org.apache.qpid.server.protocol.AMQMinaProtocolSession
 
dump() - Method in class org.apache.qpid.server.util.CircularBuffer
 

E

enabled - Variable in class org.apache.qpid.server.management.ManagementConfiguration
 
enableDirectBuffers - Variable in class org.apache.qpid.server.transport.ConnectorConfiguration
 
enableExecutorPool - Variable in class org.apache.qpid.server.transport.ConnectorConfiguration
 
enableNonSSL - Variable in class org.apache.qpid.server.transport.ConnectorConfiguration
 
enablePooledAllocator - Variable in class org.apache.qpid.server.transport.ConnectorConfiguration
 
enableSSL - Variable in class org.apache.qpid.server.transport.ConnectorConfiguration
 
enlist(TxnOp) - Method in class org.apache.qpid.server.txn.TxnBuffer
 
enqueue(AMQQueue) - Method in class org.apache.qpid.server.queue.AMQMessage
 
enqueueMessage(String, long) - Method in class org.apache.qpid.server.store.MemoryMessageStore
 
enqueueMessage(String, long) - Method in interface org.apache.qpid.server.store.MessageStore
 
equals(Object) - Method in class org.apache.qpid.server.queue.AMQQueue
 
equals(Object) - Method in class org.apache.qpid.server.queue.SubscriptionImpl
 
error(AMQException) - Method in interface org.apache.qpid.server.protocol.AMQMethodListener
Callback when an error has occurred.
error(AMQException) - Method in class org.apache.qpid.server.state.AMQStateManager
 
error(Throwable) - Method in interface org.apache.qpid.server.state.StateListener
 
evaluateResponse(byte[]) - Method in class org.apache.qpid.server.security.auth.amqplain.AmqPlainSaslServer
 
evaluateResponse(byte[]) - Method in class org.apache.qpid.server.security.auth.plain.PlainSaslServer
 
EXCEPTION - Static variable in class org.apache.qpid.server.transport.ThreadPoolFilter.EventType
 
exceptionCaught(IoSession, Throwable) - Method in class org.apache.qpid.server.protocol.AMQPFastProtocolHandler
 
exceptionCaught(IoFilter.NextFilter, IoSession, Throwable) - Method in class org.apache.qpid.server.transport.ThreadPoolFilter
 
Exchange - Interface in org.apache.qpid.server.exchange
 
ExchangeDeclareHandler - Class in org.apache.qpid.server.handler
 
ExchangeDeleteHandler - Class in org.apache.qpid.server.handler
 
ExchangeFactory - Interface in org.apache.qpid.server.exchange
 
ExchangeInitialiser - Class in org.apache.qpid.server.protocol
 
ExchangeInitialiser() - Constructor for class org.apache.qpid.server.protocol.ExchangeInitialiser
 
ExchangeInUseException - Exception in org.apache.qpid.server.exchange
 
ExchangeInUseException(String) - Constructor for exception org.apache.qpid.server.exchange.ExchangeInUseException
 
ExchangeRegistry - Interface in org.apache.qpid.server.exchange
 
execute(Runnable) - Method in class org.apache.qpid.server.handler.OnCurrentThreadExecutor
 
execute() - Method in class org.apache.qpid.server.Main
 

F

FailedDequeueException - Exception in org.apache.qpid.server.queue
Signals that the dequeue of a message from a queue failed
FailedDequeueException(String) - Constructor for exception org.apache.qpid.server.queue.FailedDequeueException
 
FailedDequeueException(String, AMQException) - Constructor for exception org.apache.qpid.server.queue.FailedDequeueException
 
fetchSessionBuffer(Queue) - Method in class org.apache.qpid.server.transport.ThreadPoolFilter
Implement this method to fetch (or pop) a ThreadPoolFilter.SessionBuffer from the given unfetchedSessionBuffers.
filterClose(IoFilter.NextFilter, IoSession) - Method in class org.apache.qpid.server.transport.ThreadPoolFilter
 
filterWrite(IoFilter.NextFilter, IoSession, IoFilter.WriteRequest) - Method in class org.apache.qpid.server.transport.ThreadPoolFilter
 
findStateTransitionHandler(AMQState, B) - Method in class org.apache.qpid.server.state.AMQStateManager
 

G

get(int) - Method in class org.apache.qpid.server.util.CircularBuffer
 
getActiveConsumerCount() - Method in interface org.apache.qpid.server.queue.ManagedQueue
Returns the total number of active subscribers to the queue.
getAmqpMajor() - Method in class org.apache.qpid.server.protocol.AMQMinaProtocolSession
Convenience methods for managing AMQP version.
getAmqpMinor() - Method in class org.apache.qpid.server.protocol.AMQMinaProtocolSession
 
getAMQProtocolSession(IoSession) - Static method in class org.apache.qpid.server.protocol.AMQMinaProtocolSession
 
getAsyncDeliveryExecutor() - Static method in class org.apache.qpid.server.queue.AsyncDeliveryConfig
 
getAuthenticationManager() - Method in class org.apache.qpid.server.registry.ConfigurationFileApplicationRegistry
 
getAuthenticationManager() - Method in interface org.apache.qpid.server.registry.IApplicationRegistry
 
getAuthenticationManager() - Method in class org.apache.qpid.server.util.NullApplicationRegistry
 
getAuthorizationID() - Method in class org.apache.qpid.server.security.auth.amqplain.AmqPlainSaslServer
 
getAuthorizationID() - Method in class org.apache.qpid.server.security.auth.plain.PlainSaslServer
 
getBufferSize() - Method in class org.apache.qpid.server.util.LoggingProxy
 
getCallbackHandler() - Method in interface org.apache.qpid.server.security.auth.AuthenticationProviderInitialiser
 
getCallbackHandler() - Method in class org.apache.qpid.server.security.auth.UsernamePasswordInitialiser
 
getChannel(int) - Method in class org.apache.qpid.server.protocol.AMQMinaProtocolSession
 
getChannel(int) - Method in interface org.apache.qpid.server.protocol.AMQProtocolSession
Get the channel for this session associated with the specified id.
getChannelId() - Method in class org.apache.qpid.server.AMQChannel
 
getChannelId() - Method in class org.apache.qpid.server.protocol.AMQMethodEvent
 
getChannels() - Method in interface org.apache.qpid.server.protocol.ManagedConnection
channel details of all the channels opened for this connection.
getConfiguration() - Method in class org.apache.qpid.server.registry.ApplicationRegistry
 
getConfiguration() - Method in interface org.apache.qpid.server.registry.IApplicationRegistry
Get the low level configuration.
getConfiguration() - Method in class org.apache.qpid.server.util.NullApplicationRegistry
 
getConfiguredObject(Class<T>) - Method in class org.apache.qpid.server.registry.ApplicationRegistry
 
getConfiguredObject(Class<T>) - Method in interface org.apache.qpid.server.registry.IApplicationRegistry
This gets access to a "configured object".
getConsumerCount() - Method in interface org.apache.qpid.server.queue.ManagedQueue
Returns the total number of subscribers to the queue.
getContentBodies() - Method in class org.apache.qpid.server.queue.AMQMessage
 
getContentBodies() - Method in exception org.apache.qpid.server.RequiredDeliveryException
 
getContentHeaderBody() - Method in class org.apache.qpid.server.queue.AMQMessage
 
getContentHeaderBody() - Method in exception org.apache.qpid.server.RequiredDeliveryException
 
getContextKey() - Method in class org.apache.qpid.server.protocol.AMQMinaProtocolSession
 
getContextKey() - Method in interface org.apache.qpid.server.protocol.AMQProtocolSession
Get the context key associated with this session.
getCurrentState() - Method in class org.apache.qpid.server.state.AMQStateManager
 
getData() - Method in class org.apache.qpid.server.transport.ThreadPoolFilter.Event
 
getDataBlock(ByteBuffer, int) - Method in class org.apache.qpid.server.queue.AMQMessage
 
getDataBlock(int, String, long) - Method in class org.apache.qpid.server.queue.AMQMessage
 
getDefaultQueue() - Method in class org.apache.qpid.server.AMQChannel
 
getDelay() - Method in class org.apache.qpid.server.protocol.HeartbeatConfig
 
getErrorCode() - Method in exception org.apache.qpid.server.RequiredDeliveryException
 
getEventQueue() - Method in class org.apache.qpid.server.transport.ThreadPoolFilter.SessionBuffer
 
getExchange(String) - Method in class org.apache.qpid.server.exchange.DefaultExchangeRegistry
 
getExchange(String) - Method in interface org.apache.qpid.server.exchange.ExchangeRegistry
 
getExchangeFactory() - Method in class org.apache.qpid.server.registry.ConfigurationFileApplicationRegistry
 
getExchangeFactory() - Method in interface org.apache.qpid.server.registry.IApplicationRegistry
 
getExchangeFactory() - Method in class org.apache.qpid.server.util.NullApplicationRegistry
 
getExchangeRegistry() - Method in class org.apache.qpid.server.registry.ConfigurationFileApplicationRegistry
 
getExchangeRegistry() - Method in interface org.apache.qpid.server.registry.IApplicationRegistry
 
getExchangeRegistry() - Method in class org.apache.qpid.server.util.NullApplicationRegistry
 
getExecutor() - Method in class org.apache.qpid.server.queue.AsyncDeliveryConfig
 
getFrameClass() - Method in exception org.apache.qpid.server.state.IllegalStateTransitionException
 
getHandler() - Method in class org.apache.qpid.server.protocol.AMQPProtocolProvider
 
getHeaders(ContentHeaderBody) - Method in class org.apache.qpid.server.exchange.HeadersExchange
 
getInstance() - Static method in class org.apache.qpid.server.handler.BasicAckMethodHandler
 
getInstance() - Static method in class org.apache.qpid.server.handler.BasicCancelMethodHandler
 
getInstance() - Static method in class org.apache.qpid.server.handler.BasicConsumeMethodHandler
 
getInstance() - Static method in class org.apache.qpid.server.handler.BasicPublishMethodHandler
 
getInstance() - Static method in class org.apache.qpid.server.handler.BasicQosHandler
 
getInstance() - Static method in class org.apache.qpid.server.handler.BasicRecoverMethodHandler
 
getInstance() - Static method in class org.apache.qpid.server.handler.ChannelCloseHandler
 
getInstance() - Static method in class org.apache.qpid.server.handler.ChannelCloseOkHandler
 
getInstance() - Static method in class org.apache.qpid.server.handler.ChannelFlowHandler
 
getInstance() - Static method in class org.apache.qpid.server.handler.ChannelOpenHandler
 
getInstance() - Static method in class org.apache.qpid.server.handler.ConnectionCloseMethodHandler
 
getInstance() - Static method in class org.apache.qpid.server.handler.ConnectionCloseOkMethodHandler
 
getInstance() - Static method in class org.apache.qpid.server.handler.ConnectionOpenMethodHandler
 
getInstance() - Static method in class org.apache.qpid.server.handler.ConnectionSecureOkMethodHandler
 
getInstance() - Static method in class org.apache.qpid.server.handler.ConnectionStartOkMethodHandler
 
getInstance() - Static method in class org.apache.qpid.server.handler.ConnectionTuneOkMethodHandler
 
getInstance() - Static method in class org.apache.qpid.server.handler.ExchangeDeclareHandler
 
getInstance() - Static method in class org.apache.qpid.server.handler.ExchangeDeleteHandler
 
getInstance() - Static method in class org.apache.qpid.server.handler.QueueBindHandler
 
getInstance() - Static method in class org.apache.qpid.server.handler.QueueDeclareHandler
 
getInstance() - Static method in class org.apache.qpid.server.handler.QueueDeleteHandler
 
getInstance() - Static method in class org.apache.qpid.server.handler.TxCommitHandler
 
getInstance() - Static method in class org.apache.qpid.server.handler.TxRollbackHandler
 
getInstance() - Static method in class org.apache.qpid.server.handler.TxSelectHandler
 
getInstance() - Static method in class org.apache.qpid.server.protocol.HeartbeatConfig
 
getInstance() - Static method in class org.apache.qpid.server.registry.ApplicationRegistry
 
getInstance(int) - Static method in class org.apache.qpid.server.registry.ApplicationRegistry
 
getKeepAliveTime() - Method in class org.apache.qpid.server.transport.ThreadPoolFilter
 
getKey() - Method in class org.apache.qpid.server.protocol.AMQMinaProtocolSession
 
getKey() - Method in interface org.apache.qpid.server.protocol.AMQProtocolSession
 
getLastIoTime() - Method in interface org.apache.qpid.server.protocol.ManagedConnection
Tells the last time, the IO operation was done.
getLocalFQDN() - Method in class org.apache.qpid.server.protocol.AMQMinaProtocolSession
Get the fully qualified domain name of the local address to which this session is bound.
getLocalFQDN() - Method in interface org.apache.qpid.server.protocol.AMQProtocolSession
Get the fully qualified domain name of the local address to which this session is bound.
getManagedObject() - Method in class org.apache.qpid.server.exchange.AbstractExchange
 
getManagedObject() - Method in interface org.apache.qpid.server.management.Managable
 
getManagedObject() - Method in class org.apache.qpid.server.protocol.AMQMinaProtocolSession
 
getManagedObject() - Method in class org.apache.qpid.server.queue.AMQQueue
 
getManagedObjectRegistry() - Method in class org.apache.qpid.server.registry.ConfigurationFileApplicationRegistry
 
getManagedObjectRegistry() - Method in interface org.apache.qpid.server.registry.IApplicationRegistry
 
getManagedObjectRegistry() - Method in class org.apache.qpid.server.util.NullApplicationRegistry
 
getManagementInterface() - Method in class org.apache.qpid.server.management.DefaultManagedObject
 
getManagementInterface() - Method in interface org.apache.qpid.server.management.ManagedObject
 
getMaximumMessageCount() - Method in interface org.apache.qpid.server.queue.ManagedQueue
Tells the maximum number of messages that can be stored in the queue.
getMaximumMessageSize() - Method in interface org.apache.qpid.server.queue.ManagedQueue
Returns the maximum size of a message (in kbytes) allowed to be accepted by the ManagedQueue.
getMaximumNumberOfAllowedChannels() - Method in interface org.apache.qpid.server.protocol.ManagedConnection
Tells the maximum number of channels that can be opened using this connection.
getMaximumPoolSize() - Method in class org.apache.qpid.server.transport.ThreadPoolFilter
 
getMBeanInfo() - Method in class org.apache.qpid.server.management.AMQManagedObject
 
getMechanismName() - Method in class org.apache.qpid.server.security.auth.amqplain.AmqPlainInitialiser
 
getMechanismName() - Method in class org.apache.qpid.server.security.auth.amqplain.AmqPlainSaslServer
 
getMechanismName() - Method in interface org.apache.qpid.server.security.auth.AuthenticationProviderInitialiser
 
getMechanismName() - Method in class org.apache.qpid.server.security.auth.CRAMMD5Initialiser
 
getMechanismName() - Method in class org.apache.qpid.server.security.auth.plain.PlainInitialiser
 
getMechanismName() - Method in class org.apache.qpid.server.security.auth.plain.PlainSaslServer
 
getMechanismNames(Map) - Method in class org.apache.qpid.server.security.auth.amqplain.AmqPlainSaslServerFactory
 
getMechanismNames(Map) - Method in class org.apache.qpid.server.security.auth.plain.PlainSaslServerFactory
 
getMechanisms() - Method in interface org.apache.qpid.server.security.auth.AuthenticationManager
 
getMechanisms() - Method in class org.apache.qpid.server.security.auth.NullAuthenticationManager
 
getMechanisms() - Method in class org.apache.qpid.server.security.auth.SASLAuthenticationManager
 
getMessage(long) - Method in class org.apache.qpid.server.store.MemoryMessageStore
 
getMessageCount() - Method in class org.apache.qpid.server.queue.AMQQueue
 
getMessageCount() - Method in interface org.apache.qpid.server.queue.ManagedQueue
Total number of messages on the queue, which are yet to be delivered to the consumer(s).
getMessageId() - Method in class org.apache.qpid.server.queue.AMQMessage
 
getMessages() - Method in class org.apache.qpid.server.queue.ConcurrentDeliveryManager
 
getMessageStore() - Method in class org.apache.qpid.server.registry.ConfigurationFileApplicationRegistry
 
getMessageStore() - Method in interface org.apache.qpid.server.registry.IApplicationRegistry
 
getMessageStore() - Method in class org.apache.qpid.server.util.NullApplicationRegistry
 
getMethod() - Method in class org.apache.qpid.server.protocol.AMQMethodEvent
 
getName() - Method in class org.apache.qpid.server.exchange.AbstractExchange.ExchangeMBean
 
getName() - Method in class org.apache.qpid.server.exchange.AbstractExchange
 
getName() - Method in interface org.apache.qpid.server.exchange.Exchange
 
getName() - Method in interface org.apache.qpid.server.exchange.ManagedExchange
Returns the name of the managed exchange.
getName() - Method in class org.apache.qpid.server.queue.AMQQueue
 
getName() - Method in interface org.apache.qpid.server.queue.ManagedQueue
Returns the Name of the ManagedQueue.
getName() - Method in class org.apache.qpid.server.security.auth.UsernamePrincipal
 
getNegotiatedProperty(String) - Method in class org.apache.qpid.server.security.auth.amqplain.AmqPlainSaslServer
 
getNegotiatedProperty(String) - Method in class org.apache.qpid.server.security.auth.plain.PlainSaslServer
 
getNewMessageId() - Method in class org.apache.qpid.server.store.MemoryMessageStore
 
getNewMessageId() - Method in interface org.apache.qpid.server.store.MessageStore
Return a valid, currently unused message id.
getNextConsumerTag() - Method in class org.apache.qpid.server.AMQChannel
 
getNextDeliveryTag() - Method in class org.apache.qpid.server.AMQChannel
 
getNextFilter() - Method in class org.apache.qpid.server.transport.ThreadPoolFilter.Event
 
getNotificationInfo() - Method in class org.apache.qpid.server.management.AMQManagedObject
 
getObjectInstanceName() - Method in class org.apache.qpid.server.exchange.AbstractExchange.ExchangeMBean
 
getObjectInstanceName() - Method in interface org.apache.qpid.server.management.ManagedObject
 
getObjectName() - Method in class org.apache.qpid.server.management.DefaultManagedObject
Created the ObjectName as per the JMX Specs
getObjectName() - Method in interface org.apache.qpid.server.management.ManagedObject
Returns the ObjectName required for the mbeanserver registration.
getOriginalState() - Method in exception org.apache.qpid.server.state.IllegalStateTransitionException
 
getOwner() - Method in class org.apache.qpid.server.queue.AMQQueue
 
getOwner() - Method in interface org.apache.qpid.server.queue.ManagedQueue
Tells the Owner of the ManagedQueue.
getParentObject() - Method in class org.apache.qpid.server.management.DefaultManagedObject
 
getParentObject() - Method in interface org.apache.qpid.server.management.ManagedObject
 
getPayload() - Method in class org.apache.qpid.server.queue.AMQMessage
 
getPoolSize() - Method in class org.apache.qpid.server.transport.ThreadPoolFilter
 
getPrefetchCount() - Method in class org.apache.qpid.server.AMQChannel
 
getPrefetchHighMarkCount() - Method in class org.apache.qpid.server.AMQChannel
 
getPrefetchLowMarkCount() - Method in class org.apache.qpid.server.AMQChannel
 
getPrefetchUnits() - Method in class org.apache.qpid.server.jms.JmsConsumer
 
getPrefetchValue() - Method in class org.apache.qpid.server.jms.JmsConsumer
 
getProperties() - Method in interface org.apache.qpid.server.security.auth.AuthenticationProviderInitialiser
Get the properties that must be passed in to the Sasl.createSaslServer method.
getProperties() - Method in class org.apache.qpid.server.security.auth.UsernamePasswordInitialiser
 
getProtocolSession() - Method in class org.apache.qpid.server.jms.JmsConsumer
 
getProxy(Class...) - Method in class org.apache.qpid.server.util.LoggingProxy
 
getPublishBody() - Method in class org.apache.qpid.server.queue.AMQMessage
 
getPublishBody() - Method in exception org.apache.qpid.server.RequiredDeliveryException
 
getPublisher() - Method in class org.apache.qpid.server.queue.AMQMessage
 
getQueue(String) - Method in class org.apache.qpid.server.queue.DefaultQueueRegistry
 
getQueue(String) - Method in interface org.apache.qpid.server.queue.QueueRegistry
 
getQueueDepth() - Method in interface org.apache.qpid.server.queue.ManagedQueue
Tells the maximum size of all the messages combined together, that can be stored in the queue.
getQueueMessageCount() - Method in class org.apache.qpid.server.queue.ConcurrentDeliveryManager
 
getQueueRegistry() - Method in class org.apache.qpid.server.registry.ConfigurationFileApplicationRegistry
 
getQueueRegistry() - Method in interface org.apache.qpid.server.registry.IApplicationRegistry
 
getQueueRegistry() - Method in class org.apache.qpid.server.util.NullApplicationRegistry
 
getQueueSize() - Method in interface org.apache.qpid.server.queue.ManagedQueue
Size of messages in the queue
getReadBytes() - Method in interface org.apache.qpid.server.protocol.ManagedConnection
Tells the total number of bytes read till now.
getReceivedMessageCount() - Method in interface org.apache.qpid.server.queue.ManagedQueue
Tells the total number of messages receieved by the queue since startup.
getRemoteAddress() - Method in interface org.apache.qpid.server.protocol.ManagedConnection
Tells the remote address of this connection.
getReplyCode() - Method in exception org.apache.qpid.server.exchange.NoRouteException
 
getReplyCode() - Method in exception org.apache.qpid.server.queue.NoConsumersException
 
getReplyCode() - Method in exception org.apache.qpid.server.RequiredDeliveryException
 
getReturnMessage(int) - Method in exception org.apache.qpid.server.RequiredDeliveryException
 
getSaslServer() - Method in class org.apache.qpid.server.protocol.AMQMinaProtocolSession
 
getSaslServer() - Method in interface org.apache.qpid.server.protocol.AMQProtocolSession
 
getServerFactoryClassForJCARegistration() - Method in class org.apache.qpid.server.security.auth.amqplain.AmqPlainInitialiser
 
getServerFactoryClassForJCARegistration() - Method in interface org.apache.qpid.server.security.auth.AuthenticationProviderInitialiser
Get the class that is the server factory.
getServerFactoryClassForJCARegistration() - Method in class org.apache.qpid.server.security.auth.CRAMMD5Initialiser
 
getServerFactoryClassForJCARegistration() - Method in class org.apache.qpid.server.security.auth.plain.PlainInitialiser
 
getSession() - Method in class org.apache.qpid.server.transport.ThreadPoolFilter.SessionBuffer
 
getSubscribers() - Method in class org.apache.qpid.server.queue.AMQQueue
 
getThreadNamePrefix() - Method in class org.apache.qpid.server.transport.ThreadPoolFilter
 
getTicket() - Method in class org.apache.qpid.server.exchange.AbstractExchange
 
getTicket() - Method in interface org.apache.qpid.server.exchange.Exchange
 
getTicketNo() - Method in class org.apache.qpid.server.exchange.AbstractExchange.ExchangeMBean
 
getTicketNo() - Method in interface org.apache.qpid.server.exchange.ManagedExchange
 
getTimeoutFactor() - Method in class org.apache.qpid.server.protocol.HeartbeatConfig
 
getTxnBuffer() - Method in class org.apache.qpid.server.queue.AMQMessage
 
getType() - Method in class org.apache.qpid.server.management.DefaultManagedObject
 
getType() - Method in interface org.apache.qpid.server.management.ManagedObject
 
getType() - Method in class org.apache.qpid.server.transport.ThreadPoolFilter.Event
 
getUnacknowledgedMessageCount() - Method in interface org.apache.qpid.server.ManagedChannel
Tells the number of unacknowledged messages in this channel.
getUnacknowledgedMessageMap() - Method in class org.apache.qpid.server.AMQChannel
Used only for testing purposes.
getWeight() - Method in interface org.apache.qpid.server.queue.WeightedSubscriptionManager
 
getWrittenBytes() - Method in interface org.apache.qpid.server.protocol.ManagedConnection
Tells the total number of bytes written till now.

H

hasActiveSubscribers() - Method in interface org.apache.qpid.server.queue.SubscriptionManager
 
hashCode() - Method in class org.apache.qpid.server.queue.AMQQueue
 
hashCode() - Method in class org.apache.qpid.server.queue.SubscriptionImpl
 
hasQueuedMessages() - Method in class org.apache.qpid.server.queue.ConcurrentDeliveryManager
 
HeadersExchange - Class in org.apache.qpid.server.exchange
An exchange that binds queues based on a set of required headers and header values and routes messages to these queues by matching the headers of the message against those with which the queues were bound.
HeadersExchange() - Constructor for class org.apache.qpid.server.exchange.HeadersExchange
 
HeartbeatConfig - Class in org.apache.qpid.server.protocol
 
HeartbeatConfig() - Constructor for class org.apache.qpid.server.protocol.HeartbeatConfig
 

I

IApplicationRegistry - Interface in org.apache.qpid.server.registry
 
IDLE - Static variable in class org.apache.qpid.server.transport.ThreadPoolFilter.EventType
 
IllegalStateTransitionException - Exception in org.apache.qpid.server.state
 
IllegalStateTransitionException(AMQState, Class) - Constructor for exception org.apache.qpid.server.state.IllegalStateTransitionException
 
incrementReference() - Method in class org.apache.qpid.server.queue.AMQMessage
Threadsafe.
init() - Method in class org.apache.qpid.server.transport.ThreadPoolFilter
 
initHeartbeats(int) - Method in class org.apache.qpid.server.protocol.AMQMinaProtocolSession
Initialise heartbeats on the session.
initHeartbeats(int) - Method in interface org.apache.qpid.server.protocol.AMQProtocolSession
Initialise heartbeats on the session.
initialise(String, boolean, int, boolean) - Method in class org.apache.qpid.server.exchange.AbstractExchange
 
initialise(String, boolean, int, boolean) - Method in interface org.apache.qpid.server.exchange.Exchange
 
initialise(ExchangeFactory, ExchangeRegistry) - Method in class org.apache.qpid.server.protocol.ExchangeInitialiser
 
initialise(IApplicationRegistry) - Static method in class org.apache.qpid.server.registry.ApplicationRegistry
 
initialise(IApplicationRegistry, int) - Static method in class org.apache.qpid.server.registry.ApplicationRegistry
 
initialise() - Method in class org.apache.qpid.server.registry.ConfigurationFileApplicationRegistry
 
initialise() - Method in interface org.apache.qpid.server.registry.IApplicationRegistry
Initialise the application registry.
initialise(String, Configuration, Map<String, PrincipalDatabase>) - Method in interface org.apache.qpid.server.security.auth.AuthenticationProviderInitialiser
Initialise the authentication provider.
initialise(String, Configuration, Map<String, PrincipalDatabase>) - Method in class org.apache.qpid.server.security.auth.UsernamePasswordInitialiser
 
initialise() - Method in class org.apache.qpid.server.util.NullApplicationRegistry
 
inTran() - Method in class org.apache.qpid.server.store.MemoryMessageStore
 
inTran() - Method in interface org.apache.qpid.server.store.MessageStore
 
invoke(Object, Method, Object[]) - Method in class org.apache.qpid.server.util.LoggingProxy
 
isAllContentReceived() - Method in class org.apache.qpid.server.queue.AMQMessage
 
isAutoAck() - Method in class org.apache.qpid.server.jms.JmsConsumer
 
isAutoDelete() - Method in class org.apache.qpid.server.exchange.AbstractExchange.ExchangeMBean
 
isAutoDelete() - Method in class org.apache.qpid.server.exchange.AbstractExchange
 
isAutoDelete() - Method in interface org.apache.qpid.server.exchange.Exchange
 
isAutoDelete() - Method in interface org.apache.qpid.server.exchange.ManagedExchange
Tells if the exchange is set for autodelete or not.
isAutoDelete() - Method in class org.apache.qpid.server.queue.AMQQueue
 
isAutoDelete() - Method in interface org.apache.qpid.server.queue.ManagedQueue
Tells if the ManagedQueue is set to AutoDelete.
isComplete() - Method in class org.apache.qpid.server.security.auth.amqplain.AmqPlainSaslServer
 
isComplete() - Method in class org.apache.qpid.server.security.auth.plain.PlainSaslServer
 
isDurable() - Method in class org.apache.qpid.server.exchange.AbstractExchange.ExchangeMBean
 
isDurable() - Method in class org.apache.qpid.server.exchange.AbstractExchange
 
isDurable() - Method in interface org.apache.qpid.server.exchange.Exchange
 
isDurable() - Method in interface org.apache.qpid.server.exchange.ManagedExchange
Tells if the exchange is durable or not.
isDurable() - Method in class org.apache.qpid.server.queue.AMQQueue
 
isDurable() - Method in interface org.apache.qpid.server.queue.ManagedQueue
Tells whether this ManagedQueue is durable or not.
isExclusive() - Method in class org.apache.qpid.server.jms.JmsConsumer
 
isNoLocal() - Method in class org.apache.qpid.server.jms.JmsConsumer
 
isPersistent() - Method in class org.apache.qpid.server.queue.AMQMessage
 
isRedelivered() - Method in class org.apache.qpid.server.queue.AMQMessage
 
isShared() - Method in class org.apache.qpid.server.queue.AMQQueue
 
isSuspended() - Method in class org.apache.qpid.server.AMQChannel
 
isSuspended() - Method in interface org.apache.qpid.server.queue.Subscription
 
isSuspended() - Method in class org.apache.qpid.server.queue.SubscriptionImpl
 
isTransactional() - Method in class org.apache.qpid.server.AMQChannel
 
isTransactional() - Method in interface org.apache.qpid.server.ManagedChannel
Tells whether the channel is transactional.
isUseSSL() - Method in class org.apache.qpid.server.protocol.AMQPFastProtocolHandler
 
iterator() - Method in class org.apache.qpid.server.util.CircularBuffer
 

J

JCAProvider - Class in org.apache.qpid.server.security.auth
 
JCAProvider(Map<String, Class<? extends SaslServerFactory>>) - Constructor for class org.apache.qpid.server.security.auth.JCAProvider
 
JmsConsumer - Class in org.apache.qpid.server.jms
 
JmsConsumer() - Constructor for class org.apache.qpid.server.jms.JmsConsumer
 
JmsConsumer.PrefetchUnits - Enum in org.apache.qpid.server.jms
 
jmxEncode(StringBuffer, int) - Static method in class org.apache.qpid.server.management.DefaultManagedObject
 
JMXManagedObjectRegistry - Class in org.apache.qpid.server.management
 
JMXManagedObjectRegistry() - Constructor for class org.apache.qpid.server.management.JMXManagedObjectRegistry
 

L

LoggingProxy - Class in org.apache.qpid.server.util
Dynamic proxy that records invocations in a fixed size circular buffer, dumping details on hitting an exception.
LoggingProxy(Object, int) - Constructor for class org.apache.qpid.server.util.LoggingProxy
 

M

Main - Class in org.apache.qpid.server
Main entry point for AMQPD.
Main(String[]) - Constructor for class org.apache.qpid.server.Main
 
main(String[]) - Static method in class org.apache.qpid.server.Main
 
main(String[]) - Static method in class org.apache.qpid.server.util.CircularBuffer
 
Main.InitException - Exception in org.apache.qpid.server
 
Managable - Interface in org.apache.qpid.server.management
Any object that can return a related MBean should implement this interface.
ManagedBroker - Interface in org.apache.qpid.server.management
The ManagedBroker is the management interface to expose management features of the Broker.
ManagedChannel - Interface in org.apache.qpid.server
The managed interface exposed to allow management of channels.
ManagedConnection - Interface in org.apache.qpid.server.protocol
The management interface exposed to allow management of Connections.
ManagedExchange - Interface in org.apache.qpid.server.exchange
The management interface exposed to allow management of an Exchange.
ManagedObject - Interface in org.apache.qpid.server.management
This should be implemented by all Managable objects.
ManagedObjectRegistry - Interface in org.apache.qpid.server.management
Handles the registration (and unregistration and so on) of managed objects.
ManagedQueue - Interface in org.apache.qpid.server.queue
The management interface exposed to allow management of a queue.
ManagementConfiguration - Class in org.apache.qpid.server.management
 
ManagementConfiguration() - Constructor for class org.apache.qpid.server.management.ManagementConfiguration
 
MBeanAttribute - Annotation Type in org.apache.qpid.server.management
Annotation for MBean attributes.
MBeanConstructor - Annotation Type in org.apache.qpid.server.management
Annotation for MBean constructors.
MBeanDescription - Annotation Type in org.apache.qpid.server.management
Annotation for MBean class.
MBeanOperation - Annotation Type in org.apache.qpid.server.management
Annotation for MBean operations.
MBeanOperationParameter - Annotation Type in org.apache.qpid.server.management
Annotation for MBean operation parameters.
MECHANISM - Static variable in class org.apache.qpid.server.security.auth.amqplain.AmqPlainSaslServer
 
MECHANISM - Static variable in class org.apache.qpid.server.security.auth.plain.PlainSaslServer
 
MemoryMessageStore - Class in org.apache.qpid.server.store
A simple message store that stores the messages in a threadsafe structure in memory.
MemoryMessageStore() - Constructor for class org.apache.qpid.server.store.MemoryMessageStore
 
message - Variable in class org.apache.qpid.server.ack.UnacknowledgedMessage
 
MessageCleanupException - Exception in org.apache.qpid.server.queue
Signals that the removal of a message once its refcount reached zero failed.
MessageCleanupException(long, AMQException) - Constructor for exception org.apache.qpid.server.queue.MessageCleanupException
 
messageReceived(IoSession, Object) - Method in class org.apache.qpid.server.protocol.AMQPFastProtocolHandler
Invoked when a message is received on a particular protocol session.
messageReceived(IoFilter.NextFilter, IoSession, Object) - Method in class org.apache.qpid.server.transport.ThreadPoolFilter
 
MessageRouter - Interface in org.apache.qpid.server.exchange
Separated out from the ExchangeRegistry interface to allow components that use only this part to have a dependency with a reduced footprint.
messageSent(IoSession, Object) - Method in class org.apache.qpid.server.protocol.AMQPFastProtocolHandler
Called after a message has been sent out on a particular protocol session
messageSent(IoFilter.NextFilter, IoSession, Object) - Method in class org.apache.qpid.server.transport.ThreadPoolFilter
 
MessageStore - Interface in org.apache.qpid.server.store
 
methodReceived(AMQStateManager, QueueRegistry, ExchangeRegistry, AMQProtocolSession, AMQMethodEvent<BasicAckBody>) - Method in class org.apache.qpid.server.handler.BasicAckMethodHandler
 
methodReceived(AMQStateManager, QueueRegistry, ExchangeRegistry, AMQProtocolSession, AMQMethodEvent<BasicCancelBody>) - Method in class org.apache.qpid.server.handler.BasicCancelMethodHandler
 
methodReceived(AMQStateManager, QueueRegistry, ExchangeRegistry, AMQProtocolSession, AMQMethodEvent<BasicConsumeBody>) - Method in class org.apache.qpid.server.handler.BasicConsumeMethodHandler
 
methodReceived(AMQStateManager, QueueRegistry, ExchangeRegistry, AMQProtocolSession, AMQMethodEvent<BasicPublishBody>) - Method in class org.apache.qpid.server.handler.BasicPublishMethodHandler
 
methodReceived(AMQStateManager, QueueRegistry, ExchangeRegistry, AMQProtocolSession, AMQMethodEvent<BasicQosBody>) - Method in class org.apache.qpid.server.handler.BasicQosHandler
 
methodReceived(AMQStateManager, QueueRegistry, ExchangeRegistry, AMQProtocolSession, AMQMethodEvent<BasicRecoverBody>) - Method in class org.apache.qpid.server.handler.BasicRecoverMethodHandler
 
methodReceived(AMQStateManager, QueueRegistry, ExchangeRegistry, AMQProtocolSession, AMQMethodEvent<ChannelCloseBody>) - Method in class org.apache.qpid.server.handler.ChannelCloseHandler
 
methodReceived(AMQStateManager, QueueRegistry, ExchangeRegistry, AMQProtocolSession, AMQMethodEvent<ChannelCloseOkBody>) - Method in class org.apache.qpid.server.handler.ChannelCloseOkHandler
 
methodReceived(AMQStateManager, QueueRegistry, ExchangeRegistry, AMQProtocolSession, AMQMethodEvent<ChannelFlowBody>) - Method in class org.apache.qpid.server.handler.ChannelFlowHandler
 
methodReceived(AMQStateManager, QueueRegistry, ExchangeRegistry, AMQProtocolSession, AMQMethodEvent<ChannelOpenBody>) - Method in class org.apache.qpid.server.handler.ChannelOpenHandler
 
methodReceived(AMQStateManager, QueueRegistry, ExchangeRegistry, AMQProtocolSession, AMQMethodEvent<ConnectionCloseBody>) - Method in class org.apache.qpid.server.handler.ConnectionCloseMethodHandler
 
methodReceived(AMQStateManager, QueueRegistry, ExchangeRegistry, AMQProtocolSession, AMQMethodEvent<ConnectionCloseOkBody>) - Method in class org.apache.qpid.server.handler.ConnectionCloseOkMethodHandler
 
methodReceived(AMQStateManager, QueueRegistry, ExchangeRegistry, AMQProtocolSession, AMQMethodEvent<ConnectionOpenBody>) - Method in class org.apache.qpid.server.handler.ConnectionOpenMethodHandler
 
methodReceived(AMQStateManager, QueueRegistry, ExchangeRegistry, AMQProtocolSession, AMQMethodEvent<ConnectionSecureOkBody>) - Method in class org.apache.qpid.server.handler.ConnectionSecureOkMethodHandler
 
methodReceived(AMQStateManager, QueueRegistry, ExchangeRegistry, AMQProtocolSession, AMQMethodEvent<ConnectionStartOkBody>) - Method in class org.apache.qpid.server.handler.ConnectionStartOkMethodHandler
 
methodReceived(AMQStateManager, QueueRegistry, ExchangeRegistry, AMQProtocolSession, AMQMethodEvent<ConnectionTuneOkBody>) - Method in class org.apache.qpid.server.handler.ConnectionTuneOkMethodHandler
 
methodReceived(AMQStateManager, QueueRegistry, ExchangeRegistry, AMQProtocolSession, AMQMethodEvent<ExchangeDeclareBody>) - Method in class org.apache.qpid.server.handler.ExchangeDeclareHandler
 
methodReceived(AMQStateManager, QueueRegistry, ExchangeRegistry, AMQProtocolSession, AMQMethodEvent<ExchangeDeleteBody>) - Method in class org.apache.qpid.server.handler.ExchangeDeleteHandler
 
methodReceived(AMQStateManager, QueueRegistry, ExchangeRegistry, AMQProtocolSession, AMQMethodEvent<QueueBindBody>) - Method in class org.apache.qpid.server.handler.QueueBindHandler
 
methodReceived(AMQStateManager, QueueRegistry, ExchangeRegistry, AMQProtocolSession, AMQMethodEvent<QueueDeclareBody>) - Method in class org.apache.qpid.server.handler.QueueDeclareHandler
 
methodReceived(AMQStateManager, QueueRegistry, ExchangeRegistry, AMQProtocolSession, AMQMethodEvent<QueueDeleteBody>) - Method in class org.apache.qpid.server.handler.QueueDeleteHandler
 
methodReceived(AMQStateManager, QueueRegistry, ExchangeRegistry, AMQProtocolSession, AMQMethodEvent<TxCommitBody>) - Method in class org.apache.qpid.server.handler.TxCommitHandler
 
methodReceived(AMQStateManager, QueueRegistry, ExchangeRegistry, AMQProtocolSession, AMQMethodEvent<TxRollbackBody>) - Method in class org.apache.qpid.server.handler.TxRollbackHandler
 
methodReceived(AMQStateManager, QueueRegistry, ExchangeRegistry, AMQProtocolSession, AMQMethodEvent<TxSelectBody>) - Method in class org.apache.qpid.server.handler.TxSelectHandler
 
methodReceived(AMQMethodEvent<B>, AMQProtocolSession, QueueRegistry, ExchangeRegistry) - Method in interface org.apache.qpid.server.protocol.AMQMethodListener
Invoked when a method frame has been received
methodReceived(AMQMethodEvent<B>, AMQProtocolSession, QueueRegistry, ExchangeRegistry) - Method in class org.apache.qpid.server.state.AMQStateManager
 
methodReceived(AMQStateManager, QueueRegistry, ExchangeRegistry, AMQProtocolSession, AMQMethodEvent<B>) - Method in interface org.apache.qpid.server.state.StateAwareMethodListener
 

N

nextSubscriber(AMQMessage) - Method in interface org.apache.qpid.server.queue.SubscriptionManager
 
NoConsumersException - Exception in org.apache.qpid.server.queue
Signals that no consumers exist for a message at a given point in time.
NoConsumersException(String, BasicPublishBody, ContentHeaderBody, List<ContentBody>) - Constructor for exception org.apache.qpid.server.queue.NoConsumersException
 
NoConsumersException(BasicPublishBody, ContentHeaderBody, List<ContentBody>) - Constructor for exception org.apache.qpid.server.queue.NoConsumersException
 
NoopManagedObjectRegistry - Class in org.apache.qpid.server.management
This managed object registry does not actually register MBeans.
NoopManagedObjectRegistry() - Constructor for class org.apache.qpid.server.management.NoopManagedObjectRegistry
 
NoRouteException - Exception in org.apache.qpid.server.exchange
Thrown by an exchange if there is no way to route a message with the mandatory flag set.
NoRouteException(String, AMQMessage) - Constructor for exception org.apache.qpid.server.exchange.NoRouteException
 
NullApplicationRegistry - Class in org.apache.qpid.server.util
 
NullApplicationRegistry() - Constructor for class org.apache.qpid.server.util.NullApplicationRegistry
 
NullAuthenticationManager - Class in org.apache.qpid.server.security.auth
 
NullAuthenticationManager() - Constructor for class org.apache.qpid.server.security.auth.NullAuthenticationManager
 

O

OnCurrentThreadExecutor - Class in org.apache.qpid.server.handler
An executor that executes the task on the current thread.
OnCurrentThreadExecutor() - Constructor for class org.apache.qpid.server.handler.OnCurrentThreadExecutor
 
OPENED - Static variable in class org.apache.qpid.server.transport.ThreadPoolFilter.EventType
 
options - Variable in class org.apache.qpid.server.Main
 
org.apache.qpid.server - package org.apache.qpid.server
 
org.apache.qpid.server.ack - package org.apache.qpid.server.ack
 
org.apache.qpid.server.configuration - package org.apache.qpid.server.configuration
 
org.apache.qpid.server.exchange - package org.apache.qpid.server.exchange
 
org.apache.qpid.server.handler - package org.apache.qpid.server.handler
 
org.apache.qpid.server.jms - package org.apache.qpid.server.jms
 
org.apache.qpid.server.management - package org.apache.qpid.server.management
 
org.apache.qpid.server.protocol - package org.apache.qpid.server.protocol
 
org.apache.qpid.server.queue - package org.apache.qpid.server.queue
 
org.apache.qpid.server.registry - package org.apache.qpid.server.registry
 
org.apache.qpid.server.security.auth - package org.apache.qpid.server.security.auth
 
org.apache.qpid.server.security.auth.amqplain - package org.apache.qpid.server.security.auth.amqplain
 
org.apache.qpid.server.security.auth.plain - package org.apache.qpid.server.security.auth.plain
 
org.apache.qpid.server.state - package org.apache.qpid.server.state
 
org.apache.qpid.server.store - package org.apache.qpid.server.store
 
org.apache.qpid.server.transport - package org.apache.qpid.server.transport
 
org.apache.qpid.server.txn - package org.apache.qpid.server.txn
 
org.apache.qpid.server.util - package org.apache.qpid.server.util
 

P

pad(int) - Static method in class org.apache.qpid.server.handler.QueueDeclareHandler
 
parseCommandline(String[]) - Method in class org.apache.qpid.server.Main
 
PasswordFilePrincipalDatabase - Class in org.apache.qpid.server.security.auth
Represents a user database where the account information is stored in a simple flat file.
PasswordFilePrincipalDatabase() - Constructor for class org.apache.qpid.server.security.auth.PasswordFilePrincipalDatabase
 
performBindings() - Method in class org.apache.qpid.server.configuration.VirtualHostConfiguration
 
PlainInitialiser - Class in org.apache.qpid.server.security.auth.plain
 
PlainInitialiser() - Constructor for class org.apache.qpid.server.security.auth.plain.PlainInitialiser
 
PlainSaslServer - Class in org.apache.qpid.server.security.auth.plain
 
PlainSaslServer(CallbackHandler) - Constructor for class org.apache.qpid.server.security.auth.plain.PlainSaslServer
 
PlainSaslServerFactory - Class in org.apache.qpid.server.security.auth.plain
 
PlainSaslServerFactory() - Constructor for class org.apache.qpid.server.security.auth.plain.PlainSaslServerFactory
 
poolSize - Variable in class org.apache.qpid.server.queue.AsyncDeliveryConfig
 
port - Variable in class org.apache.qpid.server.transport.ConnectorConfiguration
 
prepare() - Method in class org.apache.qpid.server.ack.TxAck
 
prepare() - Method in interface org.apache.qpid.server.txn.TxnOp
Do the part of the operation that updates persistent state
PrincipalDatabase - Interface in org.apache.qpid.server.security.auth
Represents a "user database" which is really a way of storing principals (i.e.
processAsync(Executor) - Method in class org.apache.qpid.server.queue.ConcurrentDeliveryManager
 
processEvent(IoFilter.NextFilter, IoSession, ThreadPoolFilter.EventType, Object) - Method in class org.apache.qpid.server.transport.ThreadPoolFilter
 
processors - Variable in class org.apache.qpid.server.transport.ConnectorConfiguration
 
processReturns(AMQProtocolSession) - Method in class org.apache.qpid.server.AMQChannel
 
protocolSession - Variable in class org.apache.qpid.server.queue.SubscriptionImpl
 
publishContentBody(ContentBody) - Method in class org.apache.qpid.server.AMQChannel
 
publishContentHeader(ContentHeaderBody) - Method in class org.apache.qpid.server.AMQChannel
 
put(AMQMessage) - Method in class org.apache.qpid.server.store.MemoryMessageStore
 
put(AMQMessage) - Method in interface org.apache.qpid.server.store.MessageStore
 

Q

queue - Variable in class org.apache.qpid.server.ack.UnacknowledgedMessage
 
QueueBindHandler - Class in org.apache.qpid.server.handler
 
QueueDeclareHandler - Class in org.apache.qpid.server.handler
 
QueueDeclareHandler() - Constructor for class org.apache.qpid.server.handler.QueueDeclareHandler
 
queueDeleted(AMQQueue) - Method in class org.apache.qpid.server.AMQChannel
Callback indicating that a queue has been deleted.
queueDeleted(AMQQueue) - Method in interface org.apache.qpid.server.queue.Subscription
 
queueDeleted(AMQQueue) - Method in class org.apache.qpid.server.queue.SubscriptionImpl
Callback indicating that a queue has been deleted.
QueueDeleteHandler - Class in org.apache.qpid.server.handler
 
QueueDeleteHandler() - Constructor for class org.apache.qpid.server.handler.QueueDeleteHandler
 
QueueDeleteHandler(boolean) - Constructor for class org.apache.qpid.server.handler.QueueDeleteHandler
 
QueueRegistry - Interface in org.apache.qpid.server.queue
 

R

READ - Static variable in class org.apache.qpid.server.transport.ThreadPoolFilter.EventType
 
RECEIVED - Static variable in class org.apache.qpid.server.transport.ThreadPoolFilter.EventType
 
register() - Method in class org.apache.qpid.server.management.DefaultManagedObject
 
register() - Method in interface org.apache.qpid.server.management.ManagedObject
 
registerExchange(Exchange) - Method in class org.apache.qpid.server.exchange.DefaultExchangeRegistry
 
registerExchange(Exchange) - Method in interface org.apache.qpid.server.exchange.ExchangeRegistry
 
registerListeners() - Method in class org.apache.qpid.server.state.AMQStateManager
 
registerObject(ManagedObject) - Method in class org.apache.qpid.server.management.JMXManagedObjectRegistry
 
registerObject(ManagedObject) - Method in interface org.apache.qpid.server.management.ManagedObjectRegistry
 
registerObject(ManagedObject) - Method in class org.apache.qpid.server.management.NoopManagedObjectRegistry
 
registerProtocolSession(AMQProtocolSession, int, String, boolean) - Method in class org.apache.qpid.server.queue.AMQQueue
 
registerQueue(String, AMQQueue, FieldTable) - Method in class org.apache.qpid.server.exchange.DestNameExchange
 
registerQueue(String, AMQQueue, FieldTable) - Method in class org.apache.qpid.server.exchange.DestWildExchange
 
registerQueue(String, AMQQueue, FieldTable) - Method in interface org.apache.qpid.server.exchange.Exchange
 
registerQueue(String, AMQQueue, FieldTable) - Method in class org.apache.qpid.server.exchange.HeadersExchange
 
registerQueue(AMQQueue) - Method in class org.apache.qpid.server.queue.DefaultQueueRegistry
 
registerQueue(AMQQueue) - Method in interface org.apache.qpid.server.queue.QueueRegistry
 
remove(List<UnacknowledgedMessage>) - Method in interface org.apache.qpid.server.ack.UnacknowledgedMessageMap
 
remove(List<UnacknowledgedMessage>) - Method in class org.apache.qpid.server.ack.UnacknowledgedMessageMapImpl
 
remove(int) - Static method in class org.apache.qpid.server.registry.ApplicationRegistry
 
removeAMessageFromTop() - Method in class org.apache.qpid.server.queue.ConcurrentDeliveryManager
 
removeChannel(int) - Method in class org.apache.qpid.server.protocol.AMQMinaProtocolSession
In our current implementation this is used by the clustering code.
removeChannel(int) - Method in interface org.apache.qpid.server.protocol.AMQProtocolSession
Remove a channel from the session but do not close it.
removeMessage(long) - Method in class org.apache.qpid.server.store.MemoryMessageStore
 
removeMessage(long) - Method in interface org.apache.qpid.server.store.MessageStore
 
removeNotificationListener(NotificationListener) - Method in class org.apache.qpid.server.management.AMQManagedObject
 
removeQueue(String) - Method in class org.apache.qpid.server.store.MemoryMessageStore
 
removeQueue(String) - Method in interface org.apache.qpid.server.store.MessageStore
 
removeStateListener(StateListener) - Method in class org.apache.qpid.server.state.AMQStateManager
 
requeue() - Method in class org.apache.qpid.server.AMQChannel
Called to attempt re-enqueue all outstanding unacknowledged messages on the channel.
RequiredDeliveryException - Exception in org.apache.qpid.server
Signals that a required delivery could not be made.
RequiredDeliveryException(String, AMQMessage) - Constructor for exception org.apache.qpid.server.RequiredDeliveryException
 
RequiredDeliveryException(String, BasicPublishBody, ContentHeaderBody, List<ContentBody>) - Constructor for exception org.apache.qpid.server.RequiredDeliveryException
 
resend(AMQProtocolSession) - Method in class org.apache.qpid.server.AMQChannel
Called to resend all outstanding unacknowledged messages to this same channel.
rollback() - Method in class org.apache.qpid.server.ack.TxAck
 
rollback() - Method in class org.apache.qpid.server.AMQChannel
 
rollback() - Method in class org.apache.qpid.server.txn.TxnBuffer
 
rollback() - Method in interface org.apache.qpid.server.txn.TxnOp
Rolls back the operation.
rollbackTransactions() - Method in interface org.apache.qpid.server.ManagedChannel
Rollsback the transactions if the channel is transactional.
rollbackTransactions(int) - Method in interface org.apache.qpid.server.protocol.ManagedConnection
Rollsback the transactions if the channel is transactional.
route(AMQMessage) - Method in class org.apache.qpid.server.exchange.DestNameExchange
 
route(AMQMessage) - Method in class org.apache.qpid.server.exchange.DestWildExchange
 
route(AMQMessage) - Method in interface org.apache.qpid.server.exchange.Exchange
 
route(AMQMessage) - Method in class org.apache.qpid.server.exchange.HeadersExchange
 
routeContent(AMQMessage) - Method in class org.apache.qpid.server.exchange.DefaultExchangeRegistry
Routes content through exchanges, delivering it to 1 or more queues.
routeContent(AMQMessage) - Method in interface org.apache.qpid.server.exchange.MessageRouter
Routes content through exchanges, delivering it to 1 or more queues.
routeCurrentMessage() - Method in class org.apache.qpid.server.AMQChannel
 

S

SASLAuthenticationManager - Class in org.apache.qpid.server.security.auth
 
SASLAuthenticationManager() - Constructor for class org.apache.qpid.server.security.auth.SASLAuthenticationManager
 
send(AMQMessage, AMQQueue) - Method in interface org.apache.qpid.server.queue.Subscription
 
send(AMQMessage, AMQQueue) - Method in class org.apache.qpid.server.queue.SubscriptionImpl
This method can be called by each of the publisher threads.
SENT - Static variable in class org.apache.qpid.server.transport.ThreadPoolFilter.EventType
 
sessionClosed(IoSession) - Method in class org.apache.qpid.server.protocol.AMQPFastProtocolHandler
 
sessionClosed(IoFilter.NextFilter, IoSession) - Method in class org.apache.qpid.server.transport.ThreadPoolFilter
 
sessionCreated(IoSession) - Method in class org.apache.qpid.server.protocol.AMQPFastProtocolHandler
 
sessionCreated(IoFilter.NextFilter, IoSession) - Method in class org.apache.qpid.server.transport.ThreadPoolFilter
 
sessionIdle(IoSession, IdleStatus) - Method in class org.apache.qpid.server.protocol.AMQPFastProtocolHandler
 
sessionIdle(IoFilter.NextFilter, IoSession, IdleStatus) - Method in class org.apache.qpid.server.transport.ThreadPoolFilter
 
sessionOpened(IoSession) - Method in class org.apache.qpid.server.protocol.AMQPFastProtocolHandler
 
sessionOpened(IoFilter.NextFilter, IoSession) - Method in class org.apache.qpid.server.transport.ThreadPoolFilter
 
setAutoAck(boolean) - Method in class org.apache.qpid.server.jms.JmsConsumer
 
setContentBodies(List<ContentBody>) - Method in class org.apache.qpid.server.queue.AMQMessage
 
setContentHeaderBody(ContentHeaderBody) - Method in class org.apache.qpid.server.queue.AMQMessage
 
setContextKey(String) - Method in class org.apache.qpid.server.protocol.AMQMinaProtocolSession
 
setContextKey(String) - Method in interface org.apache.qpid.server.protocol.AMQProtocolSession
Set the context key associated with this session.
setDefaultApplicationRegistry(String) - Static method in class org.apache.qpid.server.registry.ApplicationRegistry
 
setDefaultQueue(AMQQueue) - Method in class org.apache.qpid.server.AMQChannel
 
setDelay(int) - Method in class org.apache.qpid.server.protocol.HeartbeatConfig
 
setDeliveredToConsumer() - Method in class org.apache.qpid.server.queue.AMQMessage
Called when this message is delivered to a consumer.
setExclusive(boolean) - Method in class org.apache.qpid.server.jms.JmsConsumer
 
setKeepAliveTime(int) - Method in class org.apache.qpid.server.transport.ThreadPoolFilter
 
setMaximumMessageCount(Integer) - Method in interface org.apache.qpid.server.queue.ManagedQueue
Sets the maximum number of messages allowed to be stored in the queue.
setMaximumMessageSize(Long) - Method in interface org.apache.qpid.server.queue.ManagedQueue
Sets the maximum size of the message (in kbytes) that is allowed to be accepted by the Queue.
setMaximumNumberOfAllowedChannels(Long) - Method in interface org.apache.qpid.server.protocol.ManagedConnection
Sets the maximum number of channels allowed to be created using this connection.
setMaximumPoolSize(int) - Method in class org.apache.qpid.server.transport.ThreadPoolFilter
 
setNoLocal(boolean) - Method in class org.apache.qpid.server.jms.JmsConsumer
 
setOptions(Options) - Method in class org.apache.qpid.server.Main
 
setPassword(Principal, PasswordCallback) - Method in class org.apache.qpid.server.security.auth.PasswordFilePrincipalDatabase
 
setPassword(Principal, PasswordCallback) - Method in interface org.apache.qpid.server.security.auth.PrincipalDatabase
Set the password for a given principal in the specified callback.
setPasswordFile(String) - Method in class org.apache.qpid.server.security.auth.PasswordFilePrincipalDatabase
 
setPrefetchCount(long) - Method in class org.apache.qpid.server.AMQChannel
 
setPrefetchHighMarkCount(long) - Method in class org.apache.qpid.server.AMQChannel
 
setPrefetchLowMarkCount(long) - Method in class org.apache.qpid.server.AMQChannel
 
setPrefetchUnits(JmsConsumer.PrefetchUnits) - Method in class org.apache.qpid.server.jms.JmsConsumer
 
setPrefetchValue(int) - Method in class org.apache.qpid.server.jms.JmsConsumer
 
setProtocolSession(AMQProtocolSession) - Method in class org.apache.qpid.server.jms.JmsConsumer
 
setPublisher(AMQProtocolSession) - Method in class org.apache.qpid.server.queue.AMQMessage
 
setPublishFrame(BasicPublishBody, AMQProtocolSession) - Method in class org.apache.qpid.server.AMQChannel
 
setQueueDepth(Long) - Method in interface org.apache.qpid.server.queue.ManagedQueue
Sets the maximum size of all the messages together, that can be stored in the queue.
setSaslServer(SaslServer) - Method in class org.apache.qpid.server.protocol.AMQMinaProtocolSession
 
setSaslServer(SaslServer) - Method in interface org.apache.qpid.server.protocol.AMQProtocolSession
Set the sasl server that is to perform authentication for this session.
setSuspended(boolean) - Method in class org.apache.qpid.server.AMQChannel
 
setTimeoutFactor(double) - Method in class org.apache.qpid.server.protocol.HeartbeatConfig
 
setTransactional(boolean) - Method in class org.apache.qpid.server.AMQChannel
 
setTxnBuffer(TxnBuffer) - Method in class org.apache.qpid.server.queue.AMQMessage
 
setupVirtualHosts(String, String) - Method in class org.apache.qpid.server.Main
 
setUseSSL(boolean) - Method in class org.apache.qpid.server.protocol.AMQPFastProtocolHandler
 
size() - Method in class org.apache.qpid.server.util.CircularBuffer
 
size() - Method in class org.apache.qpid.server.util.ConcurrentLinkedQueueNoSize
 
socketReceiveBufferSize - Variable in class org.apache.qpid.server.transport.ConnectorConfiguration
 
socketWriteBuferSize - Variable in class org.apache.qpid.server.transport.ConnectorConfiguration
 
SSL_PORT - Static variable in class org.apache.qpid.server.transport.ConnectorConfiguration
 
sslPort - Variable in class org.apache.qpid.server.transport.ConnectorConfiguration
 
startup() - Method in class org.apache.qpid.server.Main
 
StateAwareMethodListener<B extends org.apache.qpid.framing.AMQMethodBody> - Interface in org.apache.qpid.server.state
A frame listener that is informed of the protocol state when invoked and has the opportunity to update state.
stateChanged(AMQState, AMQState) - Method in interface org.apache.qpid.server.state.StateListener
 
StateListener - Interface in org.apache.qpid.server.state
 
status - Variable in class org.apache.qpid.server.security.auth.AuthenticationResult
 
storeMessage() - Method in class org.apache.qpid.server.queue.AMQMessage
 
subscribeToQueue(String, AMQQueue, AMQProtocolSession, boolean) - Method in class org.apache.qpid.server.AMQChannel
Subscribe to a queue.
Subscription - Interface in org.apache.qpid.server.queue
 
SubscriptionFactory - Interface in org.apache.qpid.server.queue
Allows the customisation of the creation of a subscription.
SubscriptionImpl - Class in org.apache.qpid.server.queue
Encapsulation of a supscription to a queue.
SubscriptionImpl(int, AMQProtocolSession, String, boolean) - Constructor for class org.apache.qpid.server.queue.SubscriptionImpl
 
SubscriptionImpl(int, AMQProtocolSession, String) - Constructor for class org.apache.qpid.server.queue.SubscriptionImpl
 
SubscriptionImpl.Factory - Class in org.apache.qpid.server.queue
 
SubscriptionImpl.Factory() - Constructor for class org.apache.qpid.server.queue.SubscriptionImpl.Factory
 
SubscriptionManager - Interface in org.apache.qpid.server.queue
Abstraction of actor that will determine the subscriber to whom a message will be sent.

T

tcpNoDelay - Variable in class org.apache.qpid.server.transport.ConnectorConfiguration
 
ThreadPoolFilter - Class in org.apache.qpid.server.transport
A Thread-pooling filter.
ThreadPoolFilter() - Constructor for class org.apache.qpid.server.transport.ThreadPoolFilter
Creates a new instance of this filter with default thread pool settings.
ThreadPoolFilter(String) - Constructor for class org.apache.qpid.server.transport.ThreadPoolFilter
Creates a new instance of this filter with the specified thread name prefix and other default settings.
ThreadPoolFilter.Event - Class in org.apache.qpid.server.transport
 
ThreadPoolFilter.Event(ThreadPoolFilter.EventType, IoFilter.NextFilter, Object) - Constructor for class org.apache.qpid.server.transport.ThreadPoolFilter.Event
 
ThreadPoolFilter.EventType - Class in org.apache.qpid.server.transport
 
ThreadPoolFilter.SessionBuffer - Class in org.apache.qpid.server.transport
 
timeoutFactor - Variable in class org.apache.qpid.server.protocol.HeartbeatConfig
 
toString() - Method in class org.apache.qpid.server.AMQChannel
 
toString() - Method in class org.apache.qpid.server.exchange.AbstractExchange
 
toString() - Method in class org.apache.qpid.server.management.DefaultManagedObject
 
toString() - Method in class org.apache.qpid.server.protocol.AMQMethodEvent
 
toString() - Method in class org.apache.qpid.server.protocol.AMQMinaProtocolSession
 
toString() - Method in class org.apache.qpid.server.protocol.HeartbeatConfig
 
toString() - Method in class org.apache.qpid.server.queue.AMQQueue
 
toString() - Method in class org.apache.qpid.server.queue.SubscriptionImpl
 
toString() - Method in class org.apache.qpid.server.transport.ThreadPoolFilter.EventType
 
toString() - Method in class org.apache.qpid.server.util.CircularBuffer
 
TxAck - Class in org.apache.qpid.server.ack
A TxnOp implementation for handling accumulated acks
TxAck(UnacknowledgedMessageMap) - Constructor for class org.apache.qpid.server.ack.TxAck
 
TxCommitHandler - Class in org.apache.qpid.server.handler
 
TxnBuffer - Class in org.apache.qpid.server.txn
Holds a list of TxnOp instance representing transactional operations.
TxnBuffer(MessageStore) - Constructor for class org.apache.qpid.server.txn.TxnBuffer
 
TxnOp - Interface in org.apache.qpid.server.txn
This provides the abstraction of an individual operation within a transaction.
TxRollbackHandler - Class in org.apache.qpid.server.handler
 
TxSelectHandler - Class in org.apache.qpid.server.handler
 
TYPE - Static variable in interface org.apache.qpid.server.exchange.ManagedExchange
 
TYPE - Static variable in interface org.apache.qpid.server.ManagedChannel
 
TYPE - Static variable in interface org.apache.qpid.server.management.ManagedBroker
 
TYPE - Static variable in interface org.apache.qpid.server.protocol.ManagedConnection
 
TYPE - Static variable in interface org.apache.qpid.server.queue.ManagedQueue
 

U

UnacknowledgedMessage - Class in org.apache.qpid.server.ack
 
UnacknowledgedMessage(AMQQueue, AMQMessage, String, long) - Constructor for class org.apache.qpid.server.ack.UnacknowledgedMessage
 
UnacknowledgedMessageMap - Interface in org.apache.qpid.server.ack
 
UnacknowledgedMessageMapImpl - Class in org.apache.qpid.server.ack
 
UnacknowledgedMessageMapImpl(Object, Map<Long, UnacknowledgedMessage>) - Constructor for class org.apache.qpid.server.ack.UnacknowledgedMessageMapImpl
 
undoPrepare() - Method in class org.apache.qpid.server.ack.TxAck
 
undoPrepare() - Method in interface org.apache.qpid.server.txn.TxnOp
This is not the same as rollback.
unregister() - Method in class org.apache.qpid.server.management.DefaultManagedObject
 
unregister() - Method in interface org.apache.qpid.server.management.ManagedObject
 
unregisterExchange(String, boolean) - Method in class org.apache.qpid.server.exchange.DefaultExchangeRegistry
 
unregisterExchange(String, boolean) - Method in interface org.apache.qpid.server.exchange.ExchangeRegistry
Unregister an exchange
unregisterExchange(String) - Method in interface org.apache.qpid.server.management.ManagedBroker
unregisters all the channels, queuebindings etc and unregisters this exchange from managed objects.
unregisterObject(ManagedObject) - Method in class org.apache.qpid.server.management.JMXManagedObjectRegistry
 
unregisterObject(ManagedObject) - Method in interface org.apache.qpid.server.management.ManagedObjectRegistry
 
unregisterObject(ManagedObject) - Method in class org.apache.qpid.server.management.NoopManagedObjectRegistry
 
unregisterProtocolSession(AMQProtocolSession, int, String) - Method in class org.apache.qpid.server.queue.AMQQueue
 
unregisterQueue(String) - Method in class org.apache.qpid.server.queue.DefaultQueueRegistry
 
unregisterQueue(String) - Method in interface org.apache.qpid.server.queue.QueueRegistry
 
unsubscribeConsumer(AMQProtocolSession, String) - Method in class org.apache.qpid.server.AMQChannel
 
unwrap(byte[], int, int) - Method in class org.apache.qpid.server.security.auth.amqplain.AmqPlainSaslServer
 
unwrap(byte[], int, int) - Method in class org.apache.qpid.server.security.auth.plain.PlainSaslServer
 
update(long, boolean) - Method in class org.apache.qpid.server.ack.TxAck
 
updateReceivedMessageCount(AMQMessage) - Method in class org.apache.qpid.server.queue.AMQQueue
 
UsernamePasswordInitialiser - Class in org.apache.qpid.server.security.auth
 
UsernamePasswordInitialiser() - Constructor for class org.apache.qpid.server.security.auth.UsernamePasswordInitialiser
 
UsernamePrincipal - Class in org.apache.qpid.server.security.auth
A principal that is just a wrapper for a simple username.
UsernamePrincipal(String) - Constructor for class org.apache.qpid.server.security.auth.UsernamePrincipal
 

V

valueOf(String) - Static method in enum org.apache.qpid.server.jms.JmsConsumer.PrefetchUnits
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.qpid.server.security.auth.AuthenticationResult.AuthenticationStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.qpid.server.state.AMQState
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.qpid.server.jms.JmsConsumer.PrefetchUnits
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum org.apache.qpid.server.security.auth.AuthenticationResult.AuthenticationStatus
Returns an array containing the constants of this enum type, in the order they're declared.
values() - Static method in enum org.apache.qpid.server.state.AMQState
Returns an array containing the constants of this enum type, in the order they're declared.
viewBindings() - Method in interface org.apache.qpid.server.exchange.ManagedExchange
Returns all the bindings this exchange has with the queues.
viewMessageContent(long) - Method in interface org.apache.qpid.server.queue.ManagedQueue
 
viewMessages(int, int) - Method in interface org.apache.qpid.server.queue.ManagedQueue
Returns a subset of all the messages stored in the queue.
VirtualHostConfiguration - Class in org.apache.qpid.server.configuration
 
VirtualHostConfiguration(String) - Constructor for class org.apache.qpid.server.configuration.VirtualHostConfiguration
 

W

WeightedSubscriptionManager - Interface in org.apache.qpid.server.queue
 
wrap(byte[], int, int) - Method in class org.apache.qpid.server.security.auth.amqplain.AmqPlainSaslServer
 
wrap(byte[], int, int) - Method in class org.apache.qpid.server.security.auth.plain.PlainSaslServer
 
writeFrame(AMQDataBlock) - Method in class org.apache.qpid.server.protocol.AMQMinaProtocolSession
Convenience method that writes a frame to the protocol session.
writeFrame(AMQDataBlock) - Method in interface org.apache.qpid.server.protocol.AMQProtocolSession
Write a datablock, encoding where necessary (e.g.
WRITTEN - Static variable in class org.apache.qpid.server.transport.ThreadPoolFilter.EventType
 

_

_APPLICATION_REGISTRY - Static variable in class org.apache.qpid.server.registry.ApplicationRegistry
 
_autoDelete - Variable in class org.apache.qpid.server.exchange.AbstractExchange
Whether the exchange is automatically deleted once all queues have detached from it
_broadcaster - Variable in class org.apache.qpid.server.management.AMQManagedObject
broadcaster support class
_configuration - Variable in class org.apache.qpid.server.registry.ApplicationRegistry
 
_durable - Variable in class org.apache.qpid.server.exchange.AbstractExchange
 
_exchangeMbean - Variable in class org.apache.qpid.server.exchange.AbstractExchange
 
_mbeanInfo - Variable in class org.apache.qpid.server.management.AMQManagedObject
 
_messageMap - Variable in class org.apache.qpid.server.store.MemoryMessageStore
 
_notificationSequenceNumber - Variable in class org.apache.qpid.server.management.AMQManagedObject
sequence number for notifications
_ticket - Variable in class org.apache.qpid.server.exchange.AbstractExchange
 

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