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

ABORT - Static variable in interface org.activemq.transport.stomp.Stomp.Commands
 
ABORT_TRANSACTION - Static variable in interface org.activemq.transport.stomp.Stomp.Commands
 
AbstractDefaultWireFormat - Class in org.activemq.io.impl
Default implementation used for Java-Java protocols.
AbstractDefaultWireFormat() - Constructor for class org.activemq.io.impl.AbstractDefaultWireFormat
Default Constructor
AbstractJMSPermission - Class in org.activemq.security.jassjacc
Abstract class to make it easier to JMS Permissions.
AbstractJMSPermission(String, String) - Constructor for class org.activemq.security.jassjacc.AbstractJMSPermission
 
AbstractPacket - Class in org.activemq.message
Abstract class for a transportable Packet
AbstractPacket() - Constructor for class org.activemq.message.AbstractPacket
 
AbstractPacketMarshaller - Class in org.activemq.io.impl
 
AbstractPacketMarshaller() - Constructor for class org.activemq.io.impl.AbstractPacketMarshaller
 
AbstractPacketReader - Class in org.activemq.io.impl
Allows instances implementing Packet interface to be deserailized
AbstractPacketReader() - Constructor for class org.activemq.io.impl.AbstractPacketReader
 
AbstractPacketWriter - Class in org.activemq.io.impl
Allows instances implementing Packet interface to be serailized/deserailized
AbstractPacketWriter() - Constructor for class org.activemq.io.impl.AbstractPacketWriter
 
AbstractTransaction - Class in org.activemq.service.impl
Keeps track of all the actions the need to be done when a transaction does a commit or rollback.
AbstractTransaction() - Constructor for class org.activemq.service.impl.AbstractTransaction
 
AbstractWireFormat - Class in org.activemq.io
Represents a strategy of encoding packets on the wire or on disk using some kind of serialization or wire format.
AbstractWireFormat() - Constructor for class org.activemq.io.AbstractWireFormat
 
ACK - Static variable in interface org.activemq.transport.stomp.Stomp.Commands
 
ACK_MODE - Static variable in interface org.activemq.transport.stomp.Stomp.Headers.Subscribe
 
acknowledge(ActiveMQMessage) - Method in class org.activemq.ActiveMQSession
Acknowledges all consumed messages of the session of this consumed message.
acknowledge() - Method in class org.activemq.message.ActiveMQMessage
Acknowledges all consumed messages of the session of this consumed message.
acknowledge(ActiveMQMessage) - Method in interface org.activemq.message.MessageAcknowledge
Acknowledge receipt of this message
acknowledge(JournalTopicMessageStore, JournalAck, RecordLocation) - Method in class org.activemq.store.journal.JournalTransactionStore
 
acknowledgeMessage(BrokerClient, MessageAck) - Method in interface org.activemq.broker.Broker
Acknowledge positively or negatively, the consumption of a message by the Message Consumer
acknowledgeMessage(BrokerClient, MessageAck) - Method in interface org.activemq.broker.BrokerConnector
Acknowledge reciept of a message
acknowledgeMessage(BrokerClient, MessageAck) - Method in interface org.activemq.broker.BrokerContainer
Acknowledge reciept of a message
acknowledgeMessage(BrokerClient, MessageAck) - Method in class org.activemq.broker.impl.BrokerConnectorImpl
Acknowledge reciept of a message
acknowledgeMessage(BrokerClient, MessageAck) - Method in class org.activemq.broker.impl.BrokerContainerImpl
Acknowledge reciept of a message
acknowledgeMessage(BrokerClient, MessageAck) - Method in class org.activemq.broker.impl.DefaultBroker
Acknowledge consumption of a message by the Message Consumer
acknowledgeMessage(BrokerClient, MessageAck) - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageManager
 
acknowledgeMessage(String) - Method in class org.activemq.service.boundedvm.DurableQueueSubscription
Acknowledge the receipt of a message by a consumer
acknowledgeMessage(BrokerClient, MessageAck) - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageManager
 
acknowledgeMessage(String) - Method in class org.activemq.service.boundedvm.TransientQueueSubscription
Acknowledge the receipt of a message by a consumer
acknowledgeMessage(BrokerClient, MessageAck) - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageManager
 
acknowledgeMessage(BrokerClient, MessageAck) - Method in class org.activemq.service.impl.DurableQueueMessageContainerManager
Acknowledge a message as being read and consumed by the Consumer
acknowledgeMessage(BrokerClient, MessageAck) - Method in class org.activemq.service.impl.DurableTopicMessageContainerManager
Acknowledge a message as being read and consumed byh the Consumer
acknowledgeMessage(BrokerClient, MessageAck) - Method in class org.activemq.service.impl.ProxyMessageContainerManager
 
acknowledgeMessage(BrokerClient, MessageAck) - Method in interface org.activemq.service.MessageContainerManager
Acknowledge a message as being read and consumed by the Consumer
acknowledgeMode - Variable in class org.activemq.ActiveMQSession
 
activateObject(Object) - Method in class org.activemq.pool.SessionPool
 
activateOptions() - Method in class org.activemq.util.JmsLogAppenderSupport
 
activeConsumers(Destination) - Method in class org.activemq.advisories.ConsumerAdvisor
return a set of active ConsumerInfo's for a particular destination
ActiveIOTransportChannel - Class in org.activemq.transport.activeio
A tcp implementation of a TransportChannel
ActiveIOTransportChannel(WireFormat, AsyncChannel) - Constructor for class org.activemq.transport.activeio.ActiveIOTransportChannel
 
ActiveIOTransportChannelFactory - Class in org.activemq.transport.activeio
A tcp implementation of a TransportChannelFactory
ActiveIOTransportChannelFactory() - Constructor for class org.activemq.transport.activeio.ActiveIOTransportChannelFactory
 
ActiveIOTransportServerChannel - Class in org.activemq.transport.activeio
Binds to a well known port and listens for Sockets ...
ActiveIOTransportServerChannel(WireFormat, AsyncChannelServer) - Constructor for class org.activemq.transport.activeio.ActiveIOTransportServerChannel
 
ActiveIOTransportServerChannelFactory - Class in org.activemq.transport.activeio
A tcp implementation of a TransportServerChannelFactory
ActiveIOTransportServerChannelFactory() - Constructor for class org.activemq.transport.activeio.ActiveIOTransportServerChannelFactory
 
ACTIVEMQ_BROKER_INFO - Static variable in interface org.activemq.message.Packet
Broker infomation message
ACTIVEMQ_BYTES_MESSAGE - Static variable in interface org.activemq.message.Packet
ActiveMQBytesMessage
ACTIVEMQ_CONNECTION_INFO - Static variable in interface org.activemq.message.Packet
Connection info message
ACTIVEMQ_MAP_MESSAGE - Static variable in interface org.activemq.message.Packet
ActiveMQMapMessage object
ACTIVEMQ_MESSAGE - Static variable in interface org.activemq.message.Packet
ActiveMQMessage object
ACTIVEMQ_MSG_ACK - Static variable in interface org.activemq.message.Packet
Message acknowledge
ACTIVEMQ_OBJECT_MESSAGE - Static variable in interface org.activemq.message.Packet
ActiveMQObjectMessage object
ACTIVEMQ_QUEUE - Static variable in class org.activemq.message.ActiveMQDestination
Queue Destination object
ACTIVEMQ_STREAM_MESSAGE - Static variable in interface org.activemq.message.Packet
ActiveMQStreamMessage object
ACTIVEMQ_TEMPORARY_QUEUE - Static variable in class org.activemq.message.ActiveMQDestination
Temporary Queue Destination object
ACTIVEMQ_TEMPORARY_TOPIC - Static variable in class org.activemq.message.ActiveMQDestination
Temporary Topic Destination object
ACTIVEMQ_TEXT_MESSAGE - Static variable in interface org.activemq.message.Packet
ActiveMQTextMessage object
ACTIVEMQ_TOPIC - Static variable in class org.activemq.message.ActiveMQDestination
Topic Destination object
ActiveMQBeanDefinitionReader - Class in org.activemq.spring
 
ActiveMQBeanDefinitionReader(BeanDefinitionRegistry, String) - Constructor for class org.activemq.spring.ActiveMQBeanDefinitionReader
 
ActiveMQBeanFactory - Class in org.activemq.spring
A Spring BeanFactory for creating ActiveMQ objects
ActiveMQBeanFactory(String, Resource) - Constructor for class org.activemq.spring.ActiveMQBeanFactory
Create a new ActiveMQBeanFactory with the given resource, which must be parsable using DOM.
ActiveMQBeanFactory(String, InputStream) - Constructor for class org.activemq.spring.ActiveMQBeanFactory
Create a new ActiveMQBeanFactory with the given InputStream, which must be parsable using DOM.
ActiveMQBeanFactory(String, Resource, BeanFactory) - Constructor for class org.activemq.spring.ActiveMQBeanFactory
Create a new ActiveMQBeanFactory with the given input stream, which must be parsable using DOM.
ActiveMQBytesMessage - Class in org.activemq.message
A BytesMessage object is used to send a message containing a stream of uninterpreted bytes.
ActiveMQBytesMessage() - Constructor for class org.activemq.message.ActiveMQBytesMessage
 
ActiveMQBytesMessageReader - Class in org.activemq.io.impl
Reads a Message object to a Stream
ActiveMQBytesMessageWriter - Class in org.activemq.io.impl
Writes a Message object to a Stream
ActiveMQConnection - Class in org.activemq
A Connection object is a client's active connection to its JMS provider.
ActiveMQConnection(ActiveMQConnectionFactory, String, String, TransportChannel) - Constructor for class org.activemq.ActiveMQConnection
Constructs a connection from an existing TransportChannel and user/password.
ActiveMQConnection(ActiveMQConnectionFactory, String, String) - Constructor for class org.activemq.ActiveMQConnection
 
ActiveMQConnectionConsumer - Class in org.activemq
For application servers, Connection objects provide a special facility for creating a ConnectionConsumer (optional).
ActiveMQConnectionConsumer(ActiveMQConnection, ServerSessionPool, ConsumerInfo, int) - Constructor for class org.activemq.ActiveMQConnectionConsumer
Create a ConnectionConsumer
ActiveMQConnectionFactory - Class in org.activemq
A ConnectionFactory is an an Administed object, and is used for creating Connections.
ActiveMQConnectionFactory() - Constructor for class org.activemq.ActiveMQConnectionFactory
Default Constructor for ActiveMQConnectionFactory
ActiveMQConnectionFactory(String) - Constructor for class org.activemq.ActiveMQConnectionFactory
 
ActiveMQConnectionFactory(String, String, String) - Constructor for class org.activemq.ActiveMQConnectionFactory
 
ActiveMQConnectionFactory(BrokerContainer) - Constructor for class org.activemq.ActiveMQConnectionFactory
Constructs a ConnectionFactory with an already configured and started BrokerContainer ready for use in embedded mode.
ActiveMQConnectionFactory(BrokerContainer, String) - Constructor for class org.activemq.ActiveMQConnectionFactory
Constructs a ConnectionFactory with an already configured and started BrokerContainer ready for use in embedded mode and the brokerURL connection.
ActiveMQConnectionMetaData - Class in org.activemq
A ConnectionMetaData object provides information describing the Connection object.
ActiveMQConnectionMetaData() - Constructor for class org.activemq.ActiveMQConnectionMetaData
 
ActiveMQDestination - Class in org.activemq.message
A Destination object encapsulates a provider-specific address.
ActiveMQDestination() - Constructor for class org.activemq.message.ActiveMQDestination
The Default Constructor
ActiveMQDestination(String) - Constructor for class org.activemq.message.ActiveMQDestination
Construct the ActiveMQDestination with a defined physical name;
ActiveMQDtdResolver - Class in org.activemq.spring
EntityResolver implementation for the ActiveMQ DTD, to load the DTD from the ActiveMQ classpath JAR file.
ActiveMQDtdResolver() - Constructor for class org.activemq.spring.ActiveMQDtdResolver
 
ActiveMQInitialContextFactory - Class in org.activemq.jndi
A factory of the ActiveMQ InitialContext which contains ConnectionFactory instances as well as a child context called destinations which contain all of the current active destinations, in child context depending on the QoS such as transient or durable and queue or topic.
ActiveMQInitialContextFactory() - Constructor for class org.activemq.jndi.ActiveMQInitialContextFactory
 
ActiveMQMapMessage - Class in org.activemq.message
A MapMessage object is used to send a set of name-value pairs.
ActiveMQMapMessage() - Constructor for class org.activemq.message.ActiveMQMapMessage
 
ActiveMQMapMessageReader - Class in org.activemq.io.impl
Reads a Message object to a Stream
ActiveMQMapMessageWriter - Class in org.activemq.io.impl
Writes a Message object to a Stream
ActiveMQMessage - Class in org.activemq.message
The Message interface is the root interface of all JMS messages.
ActiveMQMessage() - Constructor for class org.activemq.message.ActiveMQMessage
 
ActiveMQMessageAudit - Class in org.activemq
Provides basic audit functions for Messages
ActiveMQMessageAudit() - Constructor for class org.activemq.ActiveMQMessageAudit
Default Constructor windowSize = 1024, maximumNumberOfProducersToTrack = 128
ActiveMQMessageAudit(int, int) - Constructor for class org.activemq.ActiveMQMessageAudit
Construct a MessageAudit
ActiveMQMessageConsumer - Class in org.activemq
A client uses a MessageConsumer object to receive messages from a destination.
ActiveMQMessageConsumer(ActiveMQSession, ActiveMQDestination, String, String, int, int, boolean, boolean) - Constructor for class org.activemq.ActiveMQMessageConsumer
Create a MessageConsumer
ActiveMQMessageDispatcher - Interface in org.activemq
An internal dispatcher for ActiveMQMessage types
ActiveMQMessageProducer - Class in org.activemq
A client uses a MessageProducer object to send messages to a destination.
ActiveMQMessageProducer(ActiveMQSession, ActiveMQDestination) - Constructor for class org.activemq.ActiveMQMessageProducer
 
ActiveMQMessageReader - Class in org.activemq.io.impl
Writes a ProducerInfo object to a Stream
ActiveMQMessageWriter - Class in org.activemq.io.impl
Writes a ActiveMQMessage packet to a Stream
ActiveMQObjectMessage - Class in org.activemq.message
An ObjectMessage object is used to send a message that contains a serializable object in the Java programming language ("Java object").
ActiveMQObjectMessage() - Constructor for class org.activemq.message.ActiveMQObjectMessage
 
ActiveMQObjectMessageReader - Class in org.activemq.io.impl
Reads a Message object to a Stream
ActiveMQObjectMessageWriter - Class in org.activemq.io.impl
Writes a Message object to a Stream
ActiveMQPrefetchPolicy - Class in org.activemq
Defines the pretech message policies for different types of consumers
ActiveMQPrefetchPolicy() - Constructor for class org.activemq.ActiveMQPrefetchPolicy
Initialize default prefetch policies
ActiveMQQueue - Class in org.activemq.message
A Queue object encapsulates a provider-specific queue name.
ActiveMQQueue() - Constructor for class org.activemq.message.ActiveMQQueue
Default constructor for an ActiveMQQueue Destination
ActiveMQQueue(String) - Constructor for class org.activemq.message.ActiveMQQueue
Construct a named ActiveMQQueue Destination
ActiveMQQueueBrowser - Class in org.activemq
A client uses a QueueBrowser object to look at messages on a queue without removing them.
ActiveMQQueueBrowser(ActiveMQSession, ActiveMQQueue, String, int) - Constructor for class org.activemq.ActiveMQQueueBrowser
Constructor for an ActiveMQQueueBrowser - used internally
ActiveMQQueueReceiver - Class in org.activemq
A client uses a QueueReceiver object to receive messages that have been delivered to a queue.
ActiveMQQueueReceiver(ActiveMQSession, ActiveMQDestination, String, int, int) - Constructor for class org.activemq.ActiveMQQueueReceiver
 
ActiveMQQueueSender - Class in org.activemq
A client uses a QueueSender object to send messages to a queue.
ActiveMQQueueSender(ActiveMQSession, ActiveMQDestination) - Constructor for class org.activemq.ActiveMQQueueSender
 
ActiveMQQueueSession - Class in org.activemq
A QueueSession implementation that throws IllegalStateExceptions when Topic operations are attempted but which delegates to another QueueSession for all other operations.
ActiveMQQueueSession(QueueSession) - Constructor for class org.activemq.ActiveMQQueueSession
 
ActiveMQSession - Class in org.activemq
A Session object is a single-threaded context for producing and consuming messages.
ActiveMQSession(ActiveMQConnection, int) - Constructor for class org.activemq.ActiveMQSession
Construct the Session
ActiveMQSession(ActiveMQConnection, int, boolean) - Constructor for class org.activemq.ActiveMQSession
Construct the Session
ActiveMQSession.DeliveryListener - Interface in org.activemq
 
ActiveMQSessionExecutor - Class in org.activemq
A utility class used by the Session for dispatching messages asynchronously to consumers
ActiveMQStreamMessage - Class in org.activemq.message
A StreamMessage object is used to send a stream of primitive types in the Java programming language.
ActiveMQStreamMessage() - Constructor for class org.activemq.message.ActiveMQStreamMessage
 
ActiveMQStreamMessageReader - Class in org.activemq.io.impl
Reads a Message object to a Stream
ActiveMQStreamMessageWriter - Class in org.activemq.io.impl
Writes a Message object to a Stream
ActiveMQTemporaryQueue - Class in org.activemq.message
A TemporaryQueue object is a unique Queue object created for the duration of a Connection.
ActiveMQTemporaryQueue() - Constructor for class org.activemq.message.ActiveMQTemporaryQueue
Default constructor for an ActiveMQTemporaryQueue Destination
ActiveMQTemporaryQueue(String) - Constructor for class org.activemq.message.ActiveMQTemporaryQueue
Construct a named ActiveMQTemporaryQueue Destination
ActiveMQTemporaryTopic - Class in org.activemq.message
A TemporaryTopic object is a unique Topic object created for the duration of a Connection.
ActiveMQTemporaryTopic() - Constructor for class org.activemq.message.ActiveMQTemporaryTopic
Default constructor for an ActiveMQTemporaryTopic Destination
ActiveMQTemporaryTopic(String) - Constructor for class org.activemq.message.ActiveMQTemporaryTopic
Construct a named ActiveMQTemporaryTopic Destination
ActiveMQTextMessage - Class in org.activemq.message
A TextMessage object is used to send a message containing a java.lang.String.
ActiveMQTextMessage() - Constructor for class org.activemq.message.ActiveMQTextMessage
 
ActiveMQTextMessageReader - Class in org.activemq.io.impl
Writes a ProducerInfo object to a Stream
ActiveMQTextMessageWriter - Class in org.activemq.io.impl
Writes a ProducerInfo object to a Stream
ActiveMQTopic - Class in org.activemq.message
A Topic object encapsulates a provider-specific topic name.
ActiveMQTopic() - Constructor for class org.activemq.message.ActiveMQTopic
Default constructor for an ActiveMQTopic Destination
ActiveMQTopic(String) - Constructor for class org.activemq.message.ActiveMQTopic
Construct a named ActiveMQTopic Destination
ActiveMQTopicPublisher - Class in org.activemq
A client uses a TopicPublisher object to publish messages on a topic.
ActiveMQTopicPublisher(ActiveMQSession, ActiveMQDestination) - Constructor for class org.activemq.ActiveMQTopicPublisher
 
ActiveMQTopicSession - Class in org.activemq
A TopicSession implementation that throws IllegalStateExceptions when Queue operations are attempted but which delegates to another TopicSession for all other operations.
ActiveMQTopicSession(TopicSession) - Constructor for class org.activemq.ActiveMQTopicSession
 
ActiveMQTopicSubscriber - Class in org.activemq
A client uses a TopicSubscriber object to receive messages that have been published to a topic.
ActiveMQTopicSubscriber(ActiveMQSession, ActiveMQDestination, String, String, int, int, boolean, boolean) - Constructor for class org.activemq.ActiveMQTopicSubscriber
 
ActiveMQWASInitialContextFactory - Class in org.activemq.jndi
This implementation of InitialContextFactory should be used when ActiveMQ is used as WebSphere Generic JMS Provider.
ActiveMQWASInitialContextFactory() - Constructor for class org.activemq.jndi.ActiveMQWASInitialContextFactory
 
ActiveMQXAConnection - Class in org.activemq
The XAConnection interface extends the capability of Connection by providing an XASession (optional).
ActiveMQXAConnection(ActiveMQConnectionFactory, String, String, TransportChannel) - Constructor for class org.activemq.ActiveMQXAConnection
 
ActiveMQXAConnection(ActiveMQConnectionFactory, String, String) - Constructor for class org.activemq.ActiveMQXAConnection
 
ActiveMQXAConnectionFactory - Class in org.activemq
The XAConnectionFactory interface is a base interface for the XAQueueConnectionFactory and XATopicConnectionFactory interfaces.
ActiveMQXAConnectionFactory() - Constructor for class org.activemq.ActiveMQXAConnectionFactory
 
ActiveMQXAConnectionFactory(String) - Constructor for class org.activemq.ActiveMQXAConnectionFactory
 
ActiveMQXAConnectionFactory(String, String, String) - Constructor for class org.activemq.ActiveMQXAConnectionFactory
 
ActiveMQXAConnectionFactory(BrokerContainer) - Constructor for class org.activemq.ActiveMQXAConnectionFactory
 
ActiveMQXAConnectionFactory(BrokerContainer, String) - Constructor for class org.activemq.ActiveMQXAConnectionFactory
 
ActiveMQXASession - Class in org.activemq
The XASession interface extends the capability of Session by adding access to a JMS provider's support for the Java Transaction API (JTA) (optional).
ActiveMQXASession(ActiveMQXAConnection, int) - Constructor for class org.activemq.ActiveMQXASession
 
ActiveMQXid - Class in org.activemq.message
A ActiveMQXid object holds the distributed transaction id that is passed around in an ActiveMQ system.
ActiveMQXid() - Constructor for class org.activemq.message.ActiveMQXid
This constructor is only used for serialization
ActiveMQXid(Xid) - Constructor for class org.activemq.message.ActiveMQXid
Creates a new ActiveMQXid object with the Xid data contained in xid
ActiveMQXid(int, byte[], byte[]) - Constructor for class org.activemq.message.ActiveMQXid
 
ActiveMQXid(byte[]) - Constructor for class org.activemq.message.ActiveMQXid
 
ActiveMQXid(String) - Constructor for class org.activemq.message.ActiveMQXid
Creates a new ActiveMQXid object.
activeProducers(Destination) - Method in class org.activemq.advisories.ProducerAdvisor
return a set of active ProducerInfo's for a particular destination
activeSubscriptions - Variable in class org.activemq.service.impl.DurableQueueMessageContainerManager
 
activeSubscriptions - Variable in class org.activemq.service.impl.DurableTopicMessageContainerManager
 
adapter - Variable in class org.activemq.store.jdbc.JDBCMessageStore
 
add(String[], int, Object) - Method in class org.activemq.filter.DestinationMapNode
 
add(MemoryBoundedObject) - Method in class org.activemq.io.util.MemoryBoundedObjectManager
 
add(MemoryBoundedQueue) - Method in class org.activemq.io.util.MemoryBoundedQueueManager
 
add(long) - Method in class org.activemq.management.CountStatisticImpl
 
add(Object) - Method in class org.activemq.service.impl.DefaultQueueList
 
add(int, Object) - Method in class org.activemq.service.impl.DefaultQueueList
 
add(Object) - Method in class org.activemq.service.impl.QueueListSupport
 
add(int, Object) - Method in class org.activemq.service.impl.QueueListSupport
 
add(Object) - Method in interface org.activemq.service.QueueList
Appends the specified element to the end of this list.
add(int, Object) - Method in interface org.activemq.service.QueueList
Inserts the specified element at the specified position in this list.
add(JournalMessageStore, ActiveMQMessage) - Method in class org.activemq.store.journal.JournalTransactionStore.Tx
 
add(JournalMessageStore, MessageAck) - Method in class org.activemq.store.journal.JournalTransactionStore.Tx
 
add(JournalTopicMessageStore, JournalAck) - Method in class org.activemq.store.journal.JournalTransactionStore.Tx
 
add(VMTransactionStore.AddMessageCommand) - Method in class org.activemq.store.vm.VMTransactionStore.Tx
 
add(VMTransactionStore.RemoveMessageCommand) - Method in class org.activemq.store.vm.VMTransactionStore.Tx
 
add_escapes(String) - Method in exception org.activemq.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.
addAckedMessage(DurableMessagePointer) - Method in class org.activemq.service.boundedvm.DurableQueueSubscription
Add an acked message.
addAckedMessage(ActiveMQMessage) - Method in class org.activemq.service.boundedvm.TransientQueueSubscription
Add an acked message.
addAckListener(AckListener) - Method in class org.activemq.transport.stomp.StompWireFormat
 
addActiveSubscription(BrokerClient, Subscription) - Method in interface org.activemq.service.Dispatcher
Add an active subscription
addActiveSubscription(BrokerClient, Subscription) - Method in class org.activemq.service.impl.DispatcherImpl
Add an active subscription
addActiveSubscription(BrokerClient, Subscription) - Method in class org.activemq.service.impl.DispatchWorker
Add an active subscription
addAllBefore(Collection, QueueListEntry) - Method in class org.activemq.service.impl.DefaultQueueList
 
addAllFirst(Collection) - Method in class org.activemq.service.impl.DefaultQueueList
 
addBefore(Object, QueueListEntry) - Method in class org.activemq.service.impl.DefaultQueueList
 
addBefore(Object, QueueListEntry) - Method in class org.activemq.service.impl.QueueListSupport
 
addBefore(Object, QueueListEntry) - Method in interface org.activemq.service.QueueList
Insert an Entry before this entry
addBrokerVisited(String) - Method in class org.activemq.message.AbstractPacket
As the packet passes through the broker add the broker to the visited list
addBrokerVisited(String) - Method in interface org.activemq.message.Packet
As the packet passes through the broker add the broker to the visited list
addCapacityEventListener(CapacityMonitorEventListener) - Method in class org.activemq.capacity.BasicCapacityMonitor
Add a CapacityMonitorEventListener
addCapacityEventListener(CapacityMonitorEventListener) - Method in interface org.activemq.capacity.CapacityMonitor
Add a CapacityMonitorEventListener
addCapacityEventListener(CapacityMonitorEventListener) - Method in class org.activemq.capacity.DelegateCapacityMonitor
Add a CapacityEventListener
addChannel(String, Map) - Method in class org.activemq.transport.DiscoveryNetworkConnector
 
addClient(BrokerClient, ConnectionInfo) - Method in interface org.activemq.broker.Broker
Notification of a new client attempting to connect, which can be rejected if authentication or authorization fails.
addClient(TransportChannel) - Method in class org.activemq.broker.impl.BrokerConnectorImpl
 
addClient(BrokerClient, ConnectionInfo) - Method in class org.activemq.broker.impl.DefaultBroker
 
addClient(TransportChannel) - Method in interface org.activemq.transport.TransportChannelListener
Called when a new channel is added to a server
addClient(TransportChannel) - Method in class org.activemq.transport.TransportServerChannelSupport
Add a channel
addConnection(ActiveMQConnection) - Method in class org.activemq.management.JMSStatsImpl
 
addConnectionConsumer(ActiveMQConnectionConsumer) - Method in class org.activemq.ActiveMQConnection
Add a ConnectionConsumer
addConnector(BrokerConnector) - Method in interface org.activemq.broker.BrokerContainer
Called when a new connector is added to this container
addConnector(String) - Method in interface org.activemq.broker.BrokerContainer
Adds a new transport connector for the given bind address
addConnector(String, WireFormat) - Method in interface org.activemq.broker.BrokerContainer
Adds a new transport connector for the given bind address and wire format
addConnector(TransportServerChannel) - Method in interface org.activemq.broker.BrokerContainer
Adds a new transport connector for the given transportConnector
addConnector(BrokerConnector) - Method in class org.activemq.broker.impl.BrokerContainerImpl
 
addConnector(String) - Method in class org.activemq.broker.impl.BrokerContainerImpl
 
addConnector(String, WireFormat) - Method in class org.activemq.broker.impl.BrokerContainerImpl
 
addConnector(TransportServerChannel) - Method in class org.activemq.broker.impl.BrokerContainerImpl
 
addConsumer(ActiveMQMessageConsumer) - Method in class org.activemq.ActiveMQSession
 
addConsumer(Filter, ConsumerInfo, BrokerClient) - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageContainer
Add a consumer to dispatch messages to
addConsumer(Filter, ConsumerInfo, BrokerClient) - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
Add a consumer to dispatch messages to
addConsumer(Filter, ConsumerInfo) - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
Add a consumer to dispatch messages to
addConsumerInfoListener(ConsumerInfoListener) - Method in interface org.activemq.broker.Broker
Add a ConsumerInfoListener to the Broker
addConsumerInfoListener(ConsumerInfoListener) - Method in class org.activemq.broker.impl.DefaultBroker
Add a ConsumerInfoListener to the Broker
addDiscoveryListener(DiscoveryListener) - Method in interface org.activemq.transport.DiscoveryAgent
Add a discovery listener
addDiscoveryListener(DiscoveryListener) - Method in class org.activemq.transport.DiscoveryAgentSupport
Add a discovery listener
addEscapes(String) - Static method in error org.activemq.selector.TokenMgrError
Replaces unprintable characters by their espaced (or unicode escaped) equivalents in the given string
addExpression() - Method in class org.activemq.selector.SelectorParser
 
addExpressionListner(Expression, MultiExpressionEvaluator.ExpressionListener) - Method in class org.activemq.filter.MultiExpressionEvaluator
Adds an ExpressionListener to a given expression.
addFirst(Object) - Method in class org.activemq.service.impl.DefaultQueueList
 
addFirst(Object) - Method in class org.activemq.service.impl.QueueListSupport
 
addFirst(Object) - Method in interface org.activemq.service.QueueList
Inserts the given element at the beginning of this list.
addKeyValuePair(Map, String) - Static method in class org.activemq.util.URIHelper
 
addLast(Object) - Method in class org.activemq.service.impl.DefaultQueueList
 
addLast(Object) - Method in class org.activemq.service.impl.QueueListSupport
 
addLast(Object) - Method in interface org.activemq.service.QueueList
Appends the given element to the end of this list.
addListener(ConnectionAdvisoryEventListener) - Method in class org.activemq.advisories.ConnectionAdvisor
Add a listener
addListener(ConsumerAdvisoryEventListener) - Method in class org.activemq.advisories.ConsumerAdvisor
Add a listener
addListener(ProducerAdvisoryEventListener) - Method in class org.activemq.advisories.ProducerAdvisor
Add a listener
addListener(TempDestinationAdvisoryEventListener) - Method in class org.activemq.advisories.TempDestinationAdvisor
Add a listener
addMessage(ActiveMQMessage) - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
 
addMessage(ActiveMQMessage) - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
 
addMessage(ActiveMQMessage) - Method in class org.activemq.service.impl.DurableQueueMessageContainer
 
addMessage(ActiveMQMessage) - Method in class org.activemq.service.impl.DurableTopicMessageContainer
 
addMessage(MessageContainer, ActiveMQMessage) - Method in class org.activemq.service.impl.SubscriptionImpl
If the Subscription is a target for the message, the subscription will add a reference to the message and register an interest in the message to the container
addMessage(ActiveMQMessage) - Method in interface org.activemq.service.MessageContainer
Add an ActiveMQMessage to the message container
addMessage(MessageContainer, ActiveMQMessage) - Method in interface org.activemq.service.Subscription
If the Subscription is a target for the message, the subscription will add a reference to the message and register an interest in the message to the container
addMessage(ActiveMQMessage) - Method in class org.activemq.store.cache.CacheMessageStore
Add the meessage to the long term store and cache it.
addMessage(ActiveMQMessage) - Method in class org.activemq.store.jdbc.JDBCMessageStore
 
addMessage(ActiveMQMessage) - Method in class org.activemq.store.journal.JournalMessageStore
Not synchronized since the Journal has better throughput if you increase the number of conncurrent writes that it is doing.
addMessage(ActiveMQMessage) - Method in interface org.activemq.store.MessageStore
Adds a message to the message store
addMessage(ActiveMQMessage) - Method in class org.activemq.store.ProxyMessageStore
 
addMessage(ActiveMQMessage) - Method in class org.activemq.store.ProxyTopicMessageStore
 
addMessage(ActiveMQMessage) - Method in class org.activemq.store.vm.VMMessageStore
 
addMessageConsumer(BrokerClient, ConsumerInfo) - Method in interface org.activemq.broker.Broker
Add an active message consumer, which could be rejected due to authorization
addMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.activemq.broker.impl.DefaultBroker
Add an active message consumer
addMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageManager
Add a consumer if appropiate
addMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageManager
Add a consumer if appropiate
addMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageManager
Add a consumer if appropiate
addMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.activemq.service.impl.DurableQueueMessageContainerManager
 
addMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.activemq.service.impl.DurableTopicMessageContainerManager
 
addMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.activemq.service.impl.InitialImageMessageContainerManager
 
addMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.activemq.service.impl.ProxyMessageContainerManager
 
addMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.activemq.service.impl.TransientTopicMessageContainerManager
 
addMessageConsumer(BrokerClient, ConsumerInfo) - Method in interface org.activemq.service.MessageContainerManager
 
addMessageDispatcher(ActiveMQMessageDispatcher) - Method in class org.activemq.ActiveMQConnection
Add a Message dispatcher to receive messages from the Broker
addMessageProducer(BrokerClient, ProducerInfo) - Method in interface org.activemq.broker.Broker
Adds a new message producer, which could be rejected due to authorization
addMessageProducer(BrokerClient, ProducerInfo) - Method in class org.activemq.broker.impl.DefaultBroker
 
addMonitoredChannel(ReliableTransportChannel) - Method in class org.activemq.transport.reliable.KeepAliveDaemon
 
addNetworkChannel(String) - Method in class org.activemq.transport.NetworkConnector
Adds a new network channel for the given URI
addNetworkChannel(NetworkChannel) - Method in class org.activemq.transport.NetworkConnector
Adds a new network channel
addNetworkConnector(String) - Method in interface org.activemq.broker.BrokerContainer
Adds a new network connector for the given URI
addNetworkConnector() - Method in interface org.activemq.broker.BrokerContainer
Adds a new network connector
addNetworkConnector(NetworkConnector) - Method in interface org.activemq.broker.BrokerContainer
Adds a new network connector
addNetworkConnector(String) - Method in class org.activemq.broker.impl.BrokerContainerImpl
 
addNetworkConnector() - Method in class org.activemq.broker.impl.BrokerContainerImpl
 
addNetworkConnector(NetworkConnector) - Method in class org.activemq.broker.impl.BrokerContainerImpl
 
addPostCommitTask(TransactionTask) - Method in class org.activemq.service.impl.AbstractTransaction
 
addPostCommitTask(TransactionTask) - Method in class org.activemq.service.impl.AutoCommitTransaction
 
addPostCommitTask(TransactionTask) - Method in interface org.activemq.service.Transaction
 
addPostRollbackTask(TransactionTask) - Method in class org.activemq.service.impl.AbstractTransaction
 
addPostRollbackTask(TransactionTask) - Method in class org.activemq.service.impl.AutoCommitTransaction
 
addPostRollbackTask(TransactionTask) - Method in interface org.activemq.service.Transaction
 
addPrePrepareTask(TransactionTask) - Method in class org.activemq.service.impl.AbstractTransaction
 
addProducer(ActiveMQMessageProducer) - Method in class org.activemq.ActiveMQSession
 
addRawPacket(Packet) - Method in class org.activemq.transport.activeio.PacketAggregator
 
addService(DiscoveryEvent) - Method in interface org.activemq.transport.DiscoveryListener
A service has started
addService(DiscoveryEvent) - Method in class org.activemq.transport.DiscoveryNetworkConnector
 
addService(DiscoveryEvent) - Method in class org.activemq.transport.DiscoveryTransportChannel
 
addSession(ActiveMQSession) - Method in class org.activemq.ActiveMQConnection
Used internally for adding Sessions to the Connection
addSession(ActiveMQSession) - Method in class org.activemq.TransactionContext
 
addShutdownHook() - Method in class org.activemq.broker.impl.BrokerContainerImpl
 
addStatistic(String, StatisticImpl) - Method in class org.activemq.management.StatsImpl
 
addSubscription(Subscription) - Method in class org.activemq.transport.stomp.StompWireFormat
 
addTime(long) - Method in class org.activemq.management.TimeStatisticImpl
 
addToEnvironment(String, Object) - Method in class org.activemq.jndi.ReadOnlyContext
 
addToTransientConsumedRedeliverCache(ActiveMQMessage) - Method in class org.activemq.ActiveMQConnection
 
addTransportStatusEventListener(TransportStatusEventListener) - Method in interface org.activemq.transport.TransportChannel
Add a listener for changes in a channels status
addTransportStatusEventListener(TransportStatusEventListener) - Method in class org.activemq.transport.TransportChannelSupport
Add a listener for changes in a channels status
addURI(URI, Map) - Method in class org.activemq.transport.DiscoveryTransportChannel
 
adjustBeginLineColumn(int, int) - Method in class org.activemq.selector.SimpleCharStream
Method to adjust line and column numbers for the start of a token.
ADVISORY_PREFIX - Static variable in class org.activemq.message.ActiveMQDestination
prefix for Advisory message destinations
afterDelivery(ActiveMQSession, Message) - Method in interface org.activemq.ActiveMQSession.DeliveryListener
 
afterMessageDelivered(boolean, ActiveMQMessage, boolean, boolean, boolean) - Method in class org.activemq.ActiveMQSession
 
afterPropertiesSet() - Method in class org.activemq.spring.BrokerFactoryBean
 
AlreadyClosedException - Exception in org.activemq
An exception which is closed if you try to access a resource which has already been closed
AlreadyClosedException() - Constructor for exception org.activemq.AlreadyClosedException
 
AlreadyClosedException(String) - Constructor for exception org.activemq.AlreadyClosedException
 
AND - Static variable in interface org.activemq.selector.SelectorParserConstants
 
andExpression() - Method in class org.activemq.selector.SelectorParser
 
AndFilter - Class in org.activemq.filter
Represents a logical AND operation on two filters
AndFilter(Filter, Filter) - Constructor for class org.activemq.filter.AndFilter
 
ANY_CHILD - Static variable in class org.activemq.filter.DestinationFilter
 
ANY_CHILD - Static variable in class org.activemq.filter.DestinationMap
 
ANY_CHILD - Static variable in class org.activemq.filter.DestinationMapNode
 
ANY_DESCENDENT - Static variable in class org.activemq.filter.DestinationFilter
 
ANY_DESCENDENT - Static variable in class org.activemq.filter.DestinationMap
 
ANY_DESCENDENT - Static variable in class org.activemq.filter.DestinationMapNode
 
append(LoggingEvent) - Method in class org.activemq.util.JmsLogAppenderSupport
 
appendDescendantValues(Set) - Method in class org.activemq.filter.DestinationMapNode
 
appendFieldDescription(StringBuffer) - Method in class org.activemq.management.BoundaryStatisticImpl
 
appendFieldDescription(StringBuffer) - Method in class org.activemq.management.BoundedRangeStatisticImpl
 
appendFieldDescription(StringBuffer) - Method in class org.activemq.management.CountStatisticImpl
 
appendFieldDescription(StringBuffer) - Method in class org.activemq.management.RangeStatisticImpl
 
appendFieldDescription(StringBuffer) - Method in class org.activemq.management.StatisticImpl
 
appendFieldDescription(StringBuffer) - Method in class org.activemq.management.TimeStatisticImpl
 
appendMatchingValues(Set, String[], int) - Method in class org.activemq.filter.DestinationMapNode
 
appendMatchingWildcards(Set, String[], int) - Method in class org.activemq.filter.DestinationMapNode
 
ArithmeticExpression - Class in org.activemq.filter
An expression which performs an operation on two expression values
ArithmeticExpression(Expression, Expression) - Constructor for class org.activemq.filter.ArithmeticExpression
 
arrays - Variable in class org.activemq.streams.JMSInputStream
 
asBoolean(int) - Method in class org.activemq.filter.ComparisonExpression
 
asBytes() - Method in class org.activemq.service.impl.QueueListSupport.Header
 
asBytes() - Method in class org.activemq.service.impl.QueueListSupport.Node
 
asNumber(Object) - Method in class org.activemq.filter.ArithmeticExpression
 
assemble(ByteArray[]) - Method in class org.activemq.io.util.ByteArrayFragmentation
Assemble a ByteArray from an array of fragements
AsyncProxy - Class in org.activemq.util
A proxy to some service which offers an asynchronous way to invoke methods which are void and don't throw exceptions.
AsyncProxy(Object, Executor) - Constructor for class org.activemq.util.AsyncProxy
 
AsyncProxy(Object, Executor, Log) - Constructor for class org.activemq.util.AsyncProxy
 
AsyncProxy(Executor, Log) - Constructor for class org.activemq.util.AsyncProxy
 
asyncSend(Packet) - Method in class org.activemq.transport.activeio.ActiveIOTransportChannel
 
asyncSend(Packet) - Method in class org.activemq.transport.composite.CompositeTransportChannel
 
asyncSend(Packet) - Method in class org.activemq.transport.reliable.ReliableTransportChannel
 
asyncSend(Packet) - Method in class org.activemq.transport.tcp.TcpTransportChannel
Asynchronously send a Packet
asyncSend(Packet) - Method in interface org.activemq.transport.TransportChannel
Asynchronously send a Packet
asyncSend(Packet) - Method in class org.activemq.transport.udp.UdpTransportChannel
Asynchronously send a Packet
asyncSend(Packet) - Method in class org.activemq.transport.vm.VmTransportChannel
Asynchronously send a Packet
asyncSendPacket(Packet) - Method in class org.activemq.ActiveMQConnection
send a Packet through the Connection - for internal use only
asyncSendPacket(Packet, boolean) - Method in class org.activemq.ActiveMQConnection
send a Packet through the Connection - for internal use only
asyncSendWithReceipt(Packet) - Method in class org.activemq.transport.composite.CompositeTransportChannel
 
asyncSendWithReceipt(Packet) - Method in class org.activemq.transport.reliable.ReliableTransportChannel
 
asyncSendWithReceipt(Packet) - Method in interface org.activemq.transport.TransportChannel
Asynchronously send a Packet with receipt.
asyncSendWithReceipt(Packet) - Method in class org.activemq.transport.TransportChannelSupport
Asynchronously send a Packet with receipt.
attemptToConnect(URI) - Method in class org.activemq.transport.composite.CompositeTransportChannel
 
authorizeConnection(BrokerClient, ConnectionInfo) - Method in class org.activemq.security.jassjacc.JassJaccSecurityAdapter
 
authorizeConnection(BrokerClient, ConnectionInfo) - Method in interface org.activemq.security.SecurityAdapter
Authenticates the connection and authorizes it for use with this Message Broker
authorizeConsumer(BrokerClient, ConsumerInfo) - Method in class org.activemq.security.jassjacc.JassJaccSecurityAdapter
 
authorizeConsumer(BrokerClient, ConsumerInfo) - Method in interface org.activemq.security.SecurityAdapter
Authorizes that the consumer can start with the given consumer information
authorizeProducer(BrokerClient, ProducerInfo) - Method in class org.activemq.security.jassjacc.JassJaccSecurityAdapter
 
authorizeProducer(BrokerClient, ProducerInfo) - Method in interface org.activemq.security.SecurityAdapter
Authorizes that the prodcuer can start with the given producer information.
authorizeReceive(BrokerClient, ActiveMQMessage) - Method in class org.activemq.security.jassjacc.JassJaccSecurityAdapter
 
authorizeReceive(BrokerClient, ActiveMQMessage) - Method in interface org.activemq.security.SecurityAdapter
Returns true if the given client is authorized to receive the given message.
authorizeSendMessage(BrokerClient, ActiveMQMessage) - Method in class org.activemq.security.jassjacc.JassJaccSecurityAdapter
 
authorizeSendMessage(BrokerClient, ActiveMQMessage) - Method in interface org.activemq.security.SecurityAdapter
Authorizes on a per message basis whether or not the client is allowed to send the given message.
AUTO - Static variable in interface org.activemq.transport.stomp.Stomp.Headers.Subscribe.AckModeValues
 
AUTO_COMMIT_TRANSACTION - Static variable in class org.activemq.service.impl.AutoCommitTransaction
 
AutoCommitTransaction - Class in org.activemq.service.impl
Keeps track of all the actions the need to be done when a transaction does a commit or rollback.
available() - Method in class org.activemq.io.util.WireByteArrayInputStream
 
available() - Method in class org.activemq.streams.JMSInputStream
Return the number of bytes available for reading.
AxionJDBCAdapter - Class in org.activemq.store.jdbc.adapter
Axion specific Adapter.
AxionJDBCAdapter() - Constructor for class org.activemq.store.jdbc.adapter.AxionJDBCAdapter
 
AxionJDBCAdapter(StatementProvider) - Constructor for class org.activemq.store.jdbc.adapter.AxionJDBCAdapter
 

B

BACKLOG - Static variable in class org.activemq.transport.tcp.SfTransportServerChannelFactory
 
backup(int) - Method in class org.activemq.selector.SimpleCharStream
 
BasicCapacityMonitor - Class in org.activemq.capacity
BasicCapacityMonitor implementation
BasicCapacityMonitor(String, long) - Constructor for class org.activemq.capacity.BasicCapacityMonitor
Construct a CapacityMonitor
BeanUtils - Class in org.activemq.util
Some bean utility methods
BeanUtils() - Constructor for class org.activemq.util.BeanUtils
 
beforeDelivery(ActiveMQSession, Message) - Method in interface org.activemq.ActiveMQSession.DeliveryListener
 
beforeMessageDelivered(ActiveMQMessage) - Method in class org.activemq.ActiveMQSession
 
begin() - Method in class org.activemq.TransactionContext
Start a local transaction.
Begin - Class in org.activemq.transport.stomp
 
Begin(StompWireFormat) - Constructor for class org.activemq.transport.stomp.Begin
 
BEGIN - Static variable in interface org.activemq.transport.stomp.Stomp.Commands
 
BEGIN_TRANSACTION - Static variable in interface org.activemq.transport.stomp.Stomp.Commands
 
beginColumn - Variable in class org.activemq.selector.Token
beginLine and beginColumn describe the position of the first character of this token; endLine and endColumn describe the position of the last character of this token.
beginEvent() - Method in interface org.activemq.LocalTransactionEventListener
 
beginLine - Variable in class org.activemq.selector.Token
beginLine and beginColumn describe the position of the first character of this token; endLine and endColumn describe the position of the last character of this token.
BeginToken() - Method in class org.activemq.selector.SimpleCharStream
 
beginTransaction() - Method in class org.activemq.store.cache.CachePersistenceAdapter
 
beginTransaction() - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
beginTransaction() - Method in class org.activemq.store.journal.JournalPersistenceAdapter
 
beginTransaction() - Method in interface org.activemq.store.PersistenceAdapter
This method starts a transaction on the persistent storage - which is nothing to do with JMS or XA transactions - its purely a mechanism to perform multiple writes to a persistent store in 1 transaction as a performance optimisation.
beginTransaction() - Method in class org.activemq.store.vm.VMPersistenceAdapter
 
BETWEEN - Static variable in interface org.activemq.selector.SelectorParserConstants
 
binaryDataType - Variable in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
BinaryExpression - Class in org.activemq.filter
An expression which performs an operation on two expression values.
BinaryExpression(Expression, Expression) - Constructor for class org.activemq.filter.BinaryExpression
 
bind(Name, Object) - Method in class org.activemq.jndi.ReadOnlyContext
 
bind(String, Object) - Method in class org.activemq.jndi.ReadOnlyContext
 
bindAddress - Variable in class org.activemq.transport.multicast.MulticastTransportServerChannel
 
bindings - Variable in class org.activemq.jndi.ReadOnlyContext
 
bitArray - Variable in class org.activemq.message.AbstractPacket
 
BitArray - Class in org.activemq.util
Simple BitArray to enable setting multiple boolean values efficently Used instead of BitSet because BitSet does not allow for efficent serialization.
BitArray() - Constructor for class org.activemq.util.BitArray
 
BitArrayBin - Class in org.activemq.util
Holder for many bitArrays - used for message audit
BitArrayBin(int) - Constructor for class org.activemq.util.BitArrayBin
Create a BitArrayBin to a certain window size (number of messages to keep)
BlobJDBCAdapter - Class in org.activemq.store.jdbc.adapter
This JDBCAdapter inserts and extracts BLOB data using the getBlob()/setBlob() operations.
BlobJDBCAdapter() - Constructor for class org.activemq.store.jdbc.adapter.BlobJDBCAdapter
 
BlobJDBCAdapter(StatementProvider) - Constructor for class org.activemq.store.jdbc.adapter.BlobJDBCAdapter
 
BLOCK_COMMENT - Static variable in interface org.activemq.selector.SelectorParserConstants
 
BodyPacket - Interface in org.activemq.message
Represents a polymorphic interface for any packet or message which has a body
BooleanExpression - Interface in org.activemq.filter
A BooleanExpression is an expression that always produces a Boolean result.
borrowSession() - Method in class org.activemq.pool.SessionPool
 
BoundaryStatisticImpl - Class in org.activemq.management
A boundary statistic implementation
BoundaryStatisticImpl(String, String, String, long, long) - Constructor for class org.activemq.management.BoundaryStatisticImpl
 
BoundedRangeStatisticImpl - Class in org.activemq.management
A bounded range statistic implementation
BoundedRangeStatisticImpl(String, String, String, long, long) - Constructor for class org.activemq.management.BoundedRangeStatisticImpl
 
Broker - Interface in org.activemq.broker
The Message Broker which routes messages, maintains subscriptions and connections, acknowlegdges messages and handles transactions.
BROKER_ADMIN_COMMAND - Static variable in interface org.activemq.message.Packet
A command to the Broker Admin
BROKER_NAME_INDEX - Static variable in class org.activemq.message.ActiveMQMessage
 
BrokerAdmin - Interface in org.activemq.broker
Provides a admin view to a broker.
BrokerAdminCommand - Class in org.activemq.message
Describes a Message consumer
BrokerAdminCommand() - Constructor for class org.activemq.message.BrokerAdminCommand
 
brokerAdminCommandReader - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
BrokerAdminCommandReader - Class in org.activemq.io.impl
Reads a BrokerAdminCommand object from a Stream
BrokerAdminCommandReader() - Constructor for class org.activemq.io.impl.BrokerAdminCommandReader
 
brokerAdminCommandWriter - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
BrokerAdminCommandWriter - Class in org.activemq.io.impl
Writes a BrokerAdminCommand object to a Stream
BrokerAdminCommandWriter() - Constructor for class org.activemq.io.impl.BrokerAdminCommandWriter
 
BrokerClient - Interface in org.activemq.broker
A Broker side proxy representing mostly outbound JMS Connnection
BrokerClientImpl - Class in org.activemq.broker.impl
A Broker client side proxy representing a JMS Connnection
BrokerClientImpl() - Constructor for class org.activemq.broker.impl.BrokerClientImpl
Default Constructor of BrokerClientImpl
BrokerConnector - Interface in org.activemq.broker
The Broker is the client side interface to the JMS server
brokerConnector - Variable in class org.activemq.transport.peer.PeerTransportChannel
 
BrokerConnectorImpl - Class in org.activemq.broker.impl
An implementation of the broker (the JMS server)
BrokerConnectorImpl(BrokerContainer, String, WireFormat) - Constructor for class org.activemq.broker.impl.BrokerConnectorImpl
Helper constructor for TCP protocol with the given bind address
BrokerConnectorImpl(BrokerContainer, TransportServerChannel) - Constructor for class org.activemq.broker.impl.BrokerConnectorImpl
 
BrokerConnectorImpl(BrokerContainer) - Constructor for class org.activemq.broker.impl.BrokerConnectorImpl
 
brokerConnectorURI - Variable in class org.activemq.transport.peer.PeerTransportChannel
 
brokerContainer - Variable in class org.activemq.ActiveMQConnectionFactory
 
BrokerContainer - Interface in org.activemq.broker
The ActiveMQ JMS Broker Container which contains a Broker and one or more instances talking over some TransportChannel

Note that once a broker container has been stopped it should be discarded and a new service instance created again.

brokerContainer - Variable in class org.activemq.transport.NetworkChannel
 
BrokerContainerFactory - Interface in org.activemq.broker
A Factory of BrokerContainer objects
BrokerContainerFactoryImpl - Class in org.activemq.broker.impl
 
BrokerContainerFactoryImpl() - Constructor for class org.activemq.broker.impl.BrokerContainerFactoryImpl
 
BrokerContainerFactoryImpl(PersistenceAdapter) - Constructor for class org.activemq.broker.impl.BrokerContainerFactoryImpl
 
BrokerContainerImpl - Class in org.activemq.broker.impl
Represents the ActiveMQ JMS Broker which typically has one or many connectors
BrokerContainerImpl() - Constructor for class org.activemq.broker.impl.BrokerContainerImpl
 
BrokerContainerImpl(String) - Constructor for class org.activemq.broker.impl.BrokerContainerImpl
 
BrokerContainerImpl(String, MemoryBoundedObjectManager) - Constructor for class org.activemq.broker.impl.BrokerContainerImpl
 
BrokerContainerImpl(String, String) - Constructor for class org.activemq.broker.impl.BrokerContainerImpl
 
BrokerContainerImpl(String, PersistenceAdapter) - Constructor for class org.activemq.broker.impl.BrokerContainerImpl
 
BrokerContainerImpl(String, BrokerContext) - Constructor for class org.activemq.broker.impl.BrokerContainerImpl
 
BrokerContainerImpl(String, BrokerContext, MemoryBoundedObjectManager) - Constructor for class org.activemq.broker.impl.BrokerContainerImpl
 
BrokerContainerImpl(String, String, BrokerContext) - Constructor for class org.activemq.broker.impl.BrokerContainerImpl
 
BrokerContainerImpl(String, PersistenceAdapter, BrokerContext) - Constructor for class org.activemq.broker.impl.BrokerContainerImpl
 
BrokerContainerImpl(String, String, PersistenceAdapter, BrokerContext) - Constructor for class org.activemq.broker.impl.BrokerContainerImpl
 
BrokerContainerImpl(Broker, BrokerContext) - Constructor for class org.activemq.broker.impl.BrokerContainerImpl
 
BrokerContext - Class in org.activemq.broker
A cache of all the brokers and broker connectors in use which is usually used in a singleton way but could be used in an IoC style manner.
BrokerContext() - Constructor for class org.activemq.broker.BrokerContext
 
BrokerFactoryBean - Class in org.activemq.spring
A Spring FactoryBean to make it easy to create an embedded broker inside Spring.
BrokerFactoryBean() - Constructor for class org.activemq.spring.BrokerFactoryBean
 
BrokerInfo - Class in org.activemq.message
Information about a connected Broker
BrokerInfo() - Constructor for class org.activemq.message.BrokerInfo
 
brokerInfoReader - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
BrokerInfoReader - Class in org.activemq.io.impl
Reads a ConsumerInfo object from a Stream
BrokerInfoReader() - Constructor for class org.activemq.io.impl.BrokerInfoReader
 
brokerInfoWriter - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
BrokerInfoWriter - Class in org.activemq.io.impl
Writes a ConsumerInfo object to a Stream
BrokerInfoWriter() - Constructor for class org.activemq.io.impl.BrokerInfoWriter
 
brokerName - Variable in class org.activemq.ActiveMQConnectionFactory
 
brokerName - Variable in class org.activemq.service.boundedvm.DurableSubscription
 
brokerName - Variable in class org.activemq.service.boundedvm.TransientSubscription
 
brokerName - Variable in class org.activemq.service.impl.SubscriptionImpl
 
brokerName - Variable in class org.activemq.transport.peer.PeerTransportChannel
 
BROKERS_VISITED_INDEX - Static variable in class org.activemq.message.AbstractPacket
 
BrokerSecurityConfig - Class in org.activemq.security.jassjacc
 
BrokerSecurityConfig() - Constructor for class org.activemq.security.jassjacc.BrokerSecurityConfig
 
brokerURL - Variable in class org.activemq.ActiveMQConnectionFactory
 
browser - Variable in class org.activemq.ActiveMQMessageConsumer
 
browsers - Variable in class org.activemq.service.impl.DurableQueueMessageContainerManager
 
bufpos - Variable in class org.activemq.selector.SimpleCharStream
 
build(String, DataInput) - Method in class org.activemq.transport.stomp.Begin
 
build(String, DataInput) - Method in class org.activemq.transport.stomp.Unsubscribe
 
buildBodyFromBytes() - Method in class org.activemq.message.ActiveMQMessage
Builds the message body from data
buildFromProperties(Properties) - Method in class org.activemq.ActiveMQConnectionFactory
Set the properties that will represent the instance in JNDI
buildFromProperties(Properties) - Method in class org.activemq.jndi.JNDIBaseStorable
Set the properties that will represent the instance in JNDI
buildFromProperties(Properties) - Method in class org.activemq.message.ActiveMQDestination
Set the properties that will represent the instance in JNDI
buildPacket(Packet, DataInput) - Method in class org.activemq.io.impl.AbstractPacketReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in class org.activemq.io.impl.ActiveMQMessageReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in class org.activemq.io.impl.BrokerAdminCommandReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in class org.activemq.io.impl.BrokerInfoReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in class org.activemq.io.impl.CachedValueReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in class org.activemq.io.impl.CapacityInfoReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in class org.activemq.io.impl.CapacityInfoRequestReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in class org.activemq.io.impl.CleanupConnectionInfoReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in class org.activemq.io.impl.ConnectionInfoReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in class org.activemq.io.impl.ConsumerInfoReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in class org.activemq.io.impl.DurableUnsubscribeReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in class org.activemq.io.impl.IntResponseReceiptReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in class org.activemq.io.impl.KeepAliveReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in class org.activemq.io.impl.MessageAckReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in interface org.activemq.io.impl.PacketReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in class org.activemq.io.impl.ProducerInfoReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in class org.activemq.io.impl.ReceiptReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in class org.activemq.io.impl.ResponseReceiptReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in class org.activemq.io.impl.SessionInfoReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in class org.activemq.io.impl.TransactionInfoReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in class org.activemq.io.impl.WireFormatInfoReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in class org.activemq.io.impl.XATransactionInfoReader
build a Packet instance from the data input stream
ByteArray - Class in org.activemq.io.util
Simple holder for a an array of Bytes - used instead of a ByteBuffer to avoid unecessary System.array() copies
ByteArray() - Constructor for class org.activemq.io.util.ByteArray
Construct an empty ByteArray
ByteArray(byte[]) - Constructor for class org.activemq.io.util.ByteArray
Create a byte array
ByteArray(byte[], int, int) - Constructor for class org.activemq.io.util.ByteArray
Create a ByteArray
ByteArrayCompression - Class in org.activemq.io.util
Compression stream
ByteArrayCompression() - Constructor for class org.activemq.io.util.ByteArrayCompression
 
ByteArrayFragmentation - Class in org.activemq.io.util
Compression stream
ByteArrayFragmentation() - Constructor for class org.activemq.io.util.ByteArrayFragmentation
 
BytesJDBCAdapter - Class in org.activemq.store.jdbc.adapter
This JDBCAdapter inserts and extracts BLOB data using the setBytes()/getBytes() operations.
BytesJDBCAdapter() - Constructor for class org.activemq.store.jdbc.adapter.BytesJDBCAdapter
 
BytesJDBCAdapter(StatementProvider) - Constructor for class org.activemq.store.jdbc.adapter.BytesJDBCAdapter
 
bytesMessageReader - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
bytesMessageWriter - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 

C

CACHED_DESTINATION_INDEX - Static variable in class org.activemq.message.ActiveMQMessage
 
CACHED_VALUE_COMMAND - Static variable in interface org.activemq.message.Packet
transmit cached values for the wire format
CACHED_VALUES_INDEX - Static variable in class org.activemq.message.ActiveMQMessage
 
CACHED_VALUES_INDEX - Static variable in class org.activemq.message.MessageAck
 
cachedBytesOut - Variable in class org.activemq.io.impl.DefaultWireFormat
 
cachedDataOut - Variable in class org.activemq.io.impl.DefaultWireFormat
 
cachedHashCode - Variable in class org.activemq.message.AbstractPacket
 
cachedKeyGenerator - Variable in class org.activemq.io.impl.DefaultWireFormat
 
CachedValue - Class in org.activemq.message
Sent in receipt of a Packet
CachedValue() - Constructor for class org.activemq.message.CachedValue
 
cachedValueReader - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
CachedValueReader - Class in org.activemq.io.impl
Reads a KeepAlive packet from a stream
CachedValueReader() - Constructor for class org.activemq.io.impl.CachedValueReader
 
cachedValueWriter - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
CachedValueWriter - Class in org.activemq.io.impl
Writes a KeepAlive object to a Stream
CachedValueWriter() - Constructor for class org.activemq.io.impl.CachedValueWriter
 
CacheMessageStore - Class in org.activemq.store.cache
A MessageStore that uses an in memory cache to speed up getMessage() method calls.
CacheMessageStore(CachePersistenceAdapter, MessageStore, MessageCache) - Constructor for class org.activemq.store.cache.CacheMessageStore
 
CacheMessageStoreAware - Interface in org.activemq.store.cache
Other MessageStores that whish to be notified when they are being cached by a CacheMessageStore should implement the CacheMessageStoreAware interface.
CachePersistenceAdapter - Class in org.activemq.store.cache
Implements a PersistenceAdapter designed to to speed up access to recently added messages by using a MessageCache .
CachePersistenceAdapter() - Constructor for class org.activemq.store.cache.CachePersistenceAdapter
 
CachePersistenceAdapter(PersistenceAdapter) - Constructor for class org.activemq.store.cache.CachePersistenceAdapter
 
CacheTopicMessageStore - Class in org.activemq.store.cache
A MessageStore that uses an in memory cache to speed up getMessage() method calls.
CacheTopicMessageStore(CachePersistenceAdapter, TopicMessageStore, MessageCache) - Constructor for class org.activemq.store.cache.CacheTopicMessageStore
 
cachingEnabled - Variable in class org.activemq.ActiveMQConnectionFactory
 
cachingEnabled - Variable in class org.activemq.io.AbstractWireFormat
 
cachingEnabled - Variable in class org.activemq.transport.TransportChannelSupport
 
CachingStatementProvider - Class in org.activemq.store.jdbc.adapter
A StatementProvider filter that caches the responses of the filtered StatementProvider.
CachingStatementProvider(StatementProvider) - Constructor for class org.activemq.store.jdbc.adapter.CachingStatementProvider
 
Callback - Interface in org.activemq.util
A simple callback object used by the TransactionTemplate and ExceptionTemplate objects to provide automatic transactional or exception handling blocks.
canAcceptMessages() - Method in class org.activemq.service.boundedvm.DurableQueueSubscription
 
canAcceptMessages() - Method in class org.activemq.service.boundedvm.TransientQueueSubscription
 
canProcessWireFormatVersion(int) - Method in class org.activemq.io.impl.AbstractDefaultWireFormat
Can this wireformat process packets of this version
canProcessWireFormatVersion(int) - Method in interface org.activemq.io.WireFormat
Can this wireformat process packets of this version
canProcessWireFormatVersion(int) - Method in class org.activemq.transport.composite.CompositeTransportChannel
Can this wireformat process packets of this version
canProcessWireFormatVersion(int) - Method in class org.activemq.transport.jabber.JabberWireFormat
Can this wireformat process packets of this version
canProcessWireFormatVersion(int) - Method in class org.activemq.transport.stomp.StompWireFormat
Can this wireformat process packets of this version
canProcessWireFormatVersion(int) - Method in class org.activemq.transport.tcp.TcpTransportChannel
Can this wireformat process packets of this version
canProcessWireFormatVersion(int) - Method in interface org.activemq.transport.TransportChannel
Can this wireformat process packets of this version
canProcessWireFormatVersion(int) - Method in class org.activemq.transport.TransportChannelSupport
Can this wireformat process packets of this version
canProcessWireFormatVersion(int) - Method in class org.activemq.transport.udp.UdpTransportChannel
Can this wireformat process packets of this version
canProcessWireFormatVersion(int) - Method in class org.activemq.transport.vm.VmTransportChannel
Can this wireformat process packets of this version
canRead(int) - Method in class org.activemq.io.impl.AbstractPacketReader
 
canRead(int) - Method in interface org.activemq.io.impl.PacketReader
 
canWrite(Packet) - Method in class org.activemq.io.impl.AbstractPacketMarshaller
 
canWrite(Packet) - Method in class org.activemq.io.impl.AbstractPacketWriter
 
canWrite(Packet) - Method in interface org.activemq.io.impl.PacketWriter
 
CAPACITY_INFO - Static variable in interface org.activemq.message.Packet
Infomation about the Capacity for more Messages for either Connection/Broker
CAPACITY_INFO_REQUEST - Static variable in interface org.activemq.message.Packet
Request infomation about the current capacity
capacityChanged(CapacityMonitorEvent) - Method in class org.activemq.ActiveMQConnection
CapacityMonitorEventListener implementation called when the capacity of a CapacityService changes
capacityChanged(CapacityMonitorEvent) - Method in class org.activemq.broker.impl.BrokerContainerImpl
Update any message producers about our capacity to handle messages
capacityChanged(CapacityMonitorEvent) - Method in interface org.activemq.capacity.CapacityMonitorEventListener
called when the capacity of a CapacityMonitor changes
CapacityInfo - Class in org.activemq.message
Infomation about the Capacity for more messages for a Connection/Broker
CapacityInfo() - Constructor for class org.activemq.message.CapacityInfo
 
capacityInfoReader - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
CapacityInfoReader - Class in org.activemq.io.impl
Reads a CapacityInfo object from a Stream
CapacityInfoReader() - Constructor for class org.activemq.io.impl.CapacityInfoReader
 
CapacityInfoRequest - Class in org.activemq.message
Request nfomation about the Capacity for more messages for a Connection/Broker
CapacityInfoRequest() - Constructor for class org.activemq.message.CapacityInfoRequest
 
capacityInfoRequestReader - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
CapacityInfoRequestReader - Class in org.activemq.io.impl
Reads a CapacityInfoRequest object from a Stream
CapacityInfoRequestReader() - Constructor for class org.activemq.io.impl.CapacityInfoRequestReader
 
capacityInfoRequestWriter - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
CapacityInfoRequestWriter - Class in org.activemq.io.impl
Writes a CapacityInfoRequest object to a Stream
CapacityInfoRequestWriter() - Constructor for class org.activemq.io.impl.CapacityInfoRequestWriter
 
capacityInfoWriter - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
CapacityInfoWriter - Class in org.activemq.io.impl
Writes a CapacityInfo object to a Stream
CapacityInfoWriter() - Constructor for class org.activemq.io.impl.CapacityInfoWriter
 
CapacityMonitor - Interface in org.activemq.capacity
Fires CapacityChangedEvents
CapacityMonitor.BasicCapacityMonitor - Class in org.activemq.capacity
A CapacityMonitor holds percentage values for some resource that has a capacity - e.g.
CapacityMonitor.BasicCapacityMonitor() - Constructor for class org.activemq.capacity.CapacityMonitor.BasicCapacityMonitor
 
CapacityMonitorEvent - Class in org.activemq.capacity
A CapacityMonitorEvent is raised to notify that a change has occurred to the capacity of a CapacityMonitor
CapacityMonitorEvent() - Constructor for class org.activemq.capacity.CapacityMonitorEvent
Default Constructor
CapacityMonitorEvent(String, int) - Constructor for class org.activemq.capacity.CapacityMonitorEvent
 
CapacityMonitorEventListener - Interface in org.activemq.capacity
A listener for CapacityChangedEvents
changeUserInfo(String, String) - Method in class org.activemq.ActiveMQConnection
Changes the associated username/password that is associated with this connection.
channel - Variable in class org.activemq.transport.composite.CompositeTransportChannel
 
channel - Variable in class org.activemq.transport.peer.PeerTransportChannel
 
charDataType - Variable in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
checkBrokerSet() - Method in class org.activemq.broker.impl.BrokerContainerImpl
 
checkClientIDWasManuallySpecified() - Method in class org.activemq.ActiveMQConnection
Ensures that the clientID was manually specified and not auto-generated.
checkClosed() - Method in class org.activemq.ActiveMQConnection
simply throws an exception if the Connection is already closed
checkClosed() - Method in class org.activemq.ActiveMQMessageConsumer
 
checkClosed() - Method in class org.activemq.ActiveMQMessageProducer
 
checkClosed() - Method in class org.activemq.ActiveMQSession
 
checkClosed() - Method in class org.activemq.streams.JMSOutputStream
Checks that the stream has not been closed
checkClosed() - Method in class org.activemq.transport.tcp.TcpBufferedOutputStream
Checks that the stream has not been closed
checkEqualOperand(Expression) - Static method in class org.activemq.filter.ComparisonExpression
Validates that the expression can be used in == or <> expression.
checkLessThanOperand(Expression) - Static method in class org.activemq.filter.ComparisonExpression
Only Numeric expressions can be used in >, >=, < or <= expressions.s
checkpoint() - Method in class org.activemq.store.journal.JournalMessageStore
 
checkpoint(boolean) - Method in class org.activemq.store.journal.JournalPersistenceAdapter
When we checkpoint we move all the journaled data to long term storage.
checkpoint() - Method in class org.activemq.store.journal.JournalTopicMessageStore
 
checkpoint() - Method in class org.activemq.store.journal.JournalTransactionStore
 
checkRunning() - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageContainer
 
checkValid() - Method in class org.activemq.broker.impl.DefaultBroker
 
CID_INDEX - Static variable in class org.activemq.message.ActiveMQMessage
 
ClassLoading - Class in org.activemq.util
Utilities for loading classes.
ClassLoading() - Constructor for class org.activemq.util.ClassLoading
 
cleanup() - Method in class org.activemq.ActiveMQConnection
Cleans up this connection so that it's state is as if the connection was just created.
cleanUp() - Method in interface org.activemq.broker.BrokerClient
Called when the transport has been terminated, so do our best to shut down any resources and deregister from any subscriptions etc
cleanUp() - Method in class org.activemq.broker.impl.BrokerClientImpl
cleanup
cleanup() - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
CLEANUP_CONNECTION_INFO - Static variable in interface org.activemq.message.Packet
transmit cached values for the wire format
cleanUpClient(BrokerClient) - Method in class org.activemq.service.impl.TransactionManagerImpl
 
cleanUpClient(BrokerClient) - Method in class org.activemq.service.TransactionManager
A hint to the TransactionManager that an BrokerClient has stopped This enables the TransactionManager to rollback in progess transactions that the client created.
cleanupConnectionAndSessionInfoReader - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
cleanupConnectionAndSessionInfoWriter - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
CleanupConnectionInfo - Class in org.activemq.message
Denotes an object that can be serialized/deserailized using a Packet Reader/Writer
CleanupConnectionInfo() - Constructor for class org.activemq.message.CleanupConnectionInfo
 
CleanupConnectionInfoReader - Class in org.activemq.io.impl
Reads a ConsumerInfo object from a Stream
CleanupConnectionInfoReader() - Constructor for class org.activemq.io.impl.CleanupConnectionInfoReader
 
CleanupConnectionInfoWriter - Class in org.activemq.io.impl
Writes a ConsumerInfo object to a Stream
CleanupConnectionInfoWriter() - Constructor for class org.activemq.io.impl.CleanupConnectionInfoWriter
 
cleanupOldMessage(Connection, MessageIdentity) - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
clear() - Method in class org.activemq.io.util.ByteArray
clear the values held by this ByteArray
clear() - Method in class org.activemq.io.util.MemoryBoundedPrioritizedQueue
remove any MemoryManageables in the queue
clear() - Method in class org.activemq.io.util.MemoryBoundedQueue
remove any MemoryManageables in the queue
clear() - Method in class org.activemq.io.util.SpooledBoundedActiveMQMessageQueue
clear the queue
clear() - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageContainer
 
clear() - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
 
clear() - Method in class org.activemq.service.impl.DefaultQueueList
 
clear() - Method in class org.activemq.service.impl.SubscriptionImpl
Called when the Subscription is discarded
clear() - Method in interface org.activemq.service.QueueList
Removes all of the elements from this list.
clear() - Method in interface org.activemq.service.Subscription
Called when the Subscription is discarded
clearBody() - Method in class org.activemq.message.ActiveMQBytesMessage
Clears out the message body.
clearBody() - Method in class org.activemq.message.ActiveMQMapMessage
Clears out the message body.
clearBody() - Method in class org.activemq.message.ActiveMQMessage
Clears out the message body.
clearBody() - Method in class org.activemq.message.ActiveMQObjectMessage
Clears out the message body.
clearBody() - Method in class org.activemq.message.ActiveMQStreamMessage
Clears out the message body.
clearBody() - Method in class org.activemq.message.ActiveMQTextMessage
Clears out the message body.
clearBrokersVisited() - Method in class org.activemq.message.AbstractPacket
clear list of brokers visited
clearBrokersVisited() - Method in interface org.activemq.message.Packet
clear list of brokers visited
clearDeliveredMessages() - Method in class org.activemq.ActiveMQSession
 
clearMessagesInProgress() - Method in class org.activemq.ActiveMQConnection
 
clearMessagesInProgress() - Method in class org.activemq.ActiveMQMessageConsumer
 
clearMessagesInProgress() - Method in class org.activemq.ActiveMQSession
 
clearMessagesInProgress() - Method in class org.activemq.ActiveMQSessionExecutor
 
clearProperties() - Method in class org.activemq.message.ActiveMQMessage
Clears a message's properties.
clen - Variable in class org.activemq.streams.JMSInputStream
 
client - Variable in class org.activemq.service.boundedvm.DurableSubscription
 
client - Variable in class org.activemq.service.boundedvm.TransientSubscription
 
CLIENT - Static variable in interface org.activemq.transport.stomp.Stomp.Headers.Subscribe.AckModeValues
 
clientID - Variable in class org.activemq.ActiveMQConnection
 
clientID - Variable in class org.activemq.ActiveMQConnectionFactory
 
clientIDsEqual(ActiveMQMessage) - Method in class org.activemq.service.impl.SubscriptionImpl
 
clone() - Method in class org.activemq.service.impl.DefaultQueueList
Returns a shallow copy of this DefaultQueueList.
close() - Method in class org.activemq.ActiveMQConnection
Closes the connection.
close() - Method in class org.activemq.ActiveMQConnectionConsumer
Closes the connection consumer.
close() - Method in class org.activemq.ActiveMQMessageConsumer
Closes the message consumer.
close() - Method in class org.activemq.ActiveMQMessageProducer
Closes the message producer.
close() - Method in class org.activemq.ActiveMQQueueBrowser
 
close() - Method in class org.activemq.ActiveMQQueueSession
 
close() - Method in class org.activemq.ActiveMQSession
Closes the session.
close() - Method in class org.activemq.ActiveMQTopicSession
 
close() - Method in class org.activemq.broker.impl.BrokerClientImpl
 
close() - Method in interface org.activemq.Closeable
Closes a JMS object.
close() - Method in class org.activemq.io.util.MemoryBoundedMessageCache
 
close() - Method in interface org.activemq.io.util.MemoryBoundedObject
 
close() - Method in class org.activemq.io.util.MemoryBoundedObjectManager
close this queue manager and all associated MemoryBoundedQueues
close() - Method in class org.activemq.io.util.MemoryBoundedQueue
close and remove this queue from the MemoryBoundedQueueManager
close() - Method in class org.activemq.io.util.MemoryBoundedQueueManager
close this queue manager and all associated MemoryBoundedQueues
close() - Method in class org.activemq.io.util.SpooledBoundedActiveMQMessageQueue
close this queue
close() - Method in class org.activemq.jndi.ReadOnlyContext
 
close() - Method in class org.activemq.message.ReceiptHolder
close this holder
close() - Method in class org.activemq.pool.PooledConnection
 
close() - Method in class org.activemq.pool.PooledProducer
 
close() - Method in class org.activemq.pool.PooledSession
 
close() - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageContainer
close down this container
close() - Method in class org.activemq.service.boundedvm.DurableQueueSubscription
close the subscription
close() - Method in class org.activemq.service.boundedvm.DurableSubscription
close the subscription
close() - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
close down this container
close() - Method in class org.activemq.service.boundedvm.TransientQueueSubscription
close the subscription
close() - Method in class org.activemq.service.boundedvm.TransientSubscription
close the subscription
close() - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
close down this container
close() - Method in interface org.activemq.store.cache.MessageCache
Lets a cache know it will not be used any further and that it can release aquired resources
close() - Method in class org.activemq.store.cache.SimpleMessageCache
 
close() - Method in class org.activemq.streams.JMSInputStream
close the stream and the MessageConsumer
close() - Method in class org.activemq.streams.JMSOutputStream
close this stream
close() - Method in class org.activemq.transport.tcp.TcpBufferedOutputStream
close this stream
close() - Method in class org.activemq.util.JmsLogAppenderSupport
 
Closeable - Interface in org.activemq
Provides a uniform interface that can be used to close all the JMS obejcts that provide a close() method.
closed - Variable in class org.activemq.ActiveMQMessageProducer
 
closed - Variable in class org.activemq.ActiveMQSession
 
closed - Variable in class org.activemq.io.util.MemoryBoundedQueue
 
closed - Variable in class org.activemq.transport.composite.CompositeTransportChannel
 
closeStreams() - Method in class org.activemq.transport.tcp.TcpTransportChannel
 
closeTemporaryDestinations() - Method in class org.activemq.ActiveMQConnection
 
CLUSTER_NAME_INDEX - Static variable in class org.activemq.message.ActiveMQMessage
 
clusterName - Variable in class org.activemq.service.boundedvm.DurableSubscription
 
clusterName - Variable in class org.activemq.service.boundedvm.TransientSubscription
 
clusterName - Variable in class org.activemq.service.impl.SubscriptionImpl
 
commit() - Method in class org.activemq.ActiveMQQueueSession
 
commit() - Method in class org.activemq.ActiveMQSession
Commits all messages done in this transaction and releases any locks currently held.
commit() - Method in class org.activemq.ActiveMQTopicSession
 
commit() - Method in class org.activemq.ActiveMQXASession
 
COMMIT - Static variable in interface org.activemq.message.TransactionType
Commit a transaction
commit() - Method in class org.activemq.pool.PooledSession
 
commit(boolean) - Method in class org.activemq.service.impl.AutoCommitTransaction
 
commit(boolean) - Method in class org.activemq.service.impl.LocalTransactionCommand
 
commit(boolean) - Method in class org.activemq.service.impl.XATransactionCommand
 
commit(boolean) - Method in interface org.activemq.service.Transaction
 
commit(Object, boolean) - Method in class org.activemq.store.journal.JournalTransactionStore
 
commit(Object, boolean) - Method in interface org.activemq.store.TransactionStore
 
commit(Object, boolean) - Method in class org.activemq.store.vm.VMTransactionStore
 
commit() - Method in class org.activemq.store.vm.VMTransactionStore.Tx
 
commit() - Method in class org.activemq.TransactionContext
Commits all messages done in this transaction and releases any locks currently held.
commit(Xid, boolean) - Method in class org.activemq.TransactionContext
 
COMMIT - Static variable in interface org.activemq.transport.stomp.Stomp.Commands
 
COMMIT_ONE_PHASE - Static variable in interface org.activemq.message.TransactionType
Do a one phase commit...
COMMIT_TRANSACTION - Static variable in interface org.activemq.transport.stomp.Stomp.Commands
 
commitEvent() - Method in interface org.activemq.LocalTransactionEventListener
 
commitTransaction(BrokerClient, String) - Method in interface org.activemq.broker.Broker
commit a transaction
commitTransaction(BrokerClient, ActiveMQXid, boolean) - Method in interface org.activemq.broker.Broker
 
commitTransaction(BrokerClient, String) - Method in interface org.activemq.broker.BrokerConnector
Commit a transaction
commitTransaction(BrokerClient, ActiveMQXid, boolean) - Method in interface org.activemq.broker.BrokerConnector
Commit an XA transaction.
commitTransaction(BrokerClient, String) - Method in interface org.activemq.broker.BrokerContainer
Commit a transaction
commitTransaction(BrokerClient, ActiveMQXid, boolean) - Method in interface org.activemq.broker.BrokerContainer
Commit an XA transaction.
commitTransaction(BrokerClient, String) - Method in class org.activemq.broker.impl.BrokerConnectorImpl
Commit a transaction
commitTransaction(BrokerClient, ActiveMQXid, boolean) - Method in class org.activemq.broker.impl.BrokerConnectorImpl
Commit an XA transaction.
commitTransaction(BrokerClient, String) - Method in class org.activemq.broker.impl.BrokerContainerImpl
Commit a transaction
commitTransaction(BrokerClient, ActiveMQXid, boolean) - Method in class org.activemq.broker.impl.BrokerContainerImpl
Commit an XA transaction.
commitTransaction(BrokerClient, String) - Method in class org.activemq.broker.impl.DefaultBroker
 
commitTransaction(BrokerClient, ActiveMQXid, boolean) - Method in class org.activemq.broker.impl.DefaultBroker
Commit an XA Transaction.
commitTransaction() - Method in class org.activemq.store.cache.CachePersistenceAdapter
 
commitTransaction() - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
commitTransaction() - Method in class org.activemq.store.journal.JournalPersistenceAdapter
 
commitTransaction() - Method in interface org.activemq.store.PersistenceAdapter
Commit a persistence transaction
commitTransaction() - Method in class org.activemq.store.vm.VMPersistenceAdapter
 
compare(Comparable, Comparable) - Method in class org.activemq.filter.ComparisonExpression
 
compare(Object, Object) - Method in class org.activemq.util.DefaultComparator
 
compare(String, String) - Static method in class org.activemq.util.IdGenerator
Does a proper compare on the ids
compareTo(Object) - Method in class org.activemq.message.ActiveMQDestination
 
compareTo(ActiveMQDestination) - Method in class org.activemq.message.ActiveMQDestination
Lets sort by name first then lets sort topics greater than queues
compareTo(Object) - Method in class org.activemq.message.ActiveMQMessage
 
compareTo(ActiveMQMessage) - Method in class org.activemq.message.ActiveMQMessage
Sorted by destination and then messageId
compareTo(Object) - Method in class org.activemq.message.ActiveMQXid
 
compareTo(byte[], byte[]) - Method in class org.activemq.message.ActiveMQXid
 
compareTo(Object) - Method in class org.activemq.service.MessageIdentity
 
ComparisonExpression - Class in org.activemq.filter
A filter performing a comparison of two objects
ComparisonExpression(Expression, Expression) - Constructor for class org.activemq.filter.ComparisonExpression
 
comparisonExpression() - Method in class org.activemq.selector.SelectorParser
 
composeName(Name, Name) - Method in class org.activemq.jndi.ReadOnlyContext
 
composeName(String, String) - Method in class org.activemq.jndi.ReadOnlyContext
 
CompositeDestinationFilter - Class in org.activemq.filter
A DestinationFilter used for composite destinations
CompositeDestinationFilter(ActiveMQDestination) - Constructor for class org.activemq.filter.CompositeDestinationFilter
 
CompositeTransportChannel - Class in org.activemq.transport.composite
A Compsite implementation of a TransportChannel
CompositeTransportChannel(WireFormat) - Constructor for class org.activemq.transport.composite.CompositeTransportChannel
 
CompositeTransportChannel(WireFormat, List) - Constructor for class org.activemq.transport.composite.CompositeTransportChannel
 
CompositeTransportChannelFactory - Class in org.activemq.transport.composite
A Composite implementation of a TransportChannelFactory
CompositeTransportChannelFactory() - Constructor for class org.activemq.transport.composite.CompositeTransportChannelFactory
 
ConfigurationException - Exception in org.activemq
An exception thrown when a service is not correctly configured
ConfigurationException(String) - Constructor for exception org.activemq.ConfigurationException
 
ConfigurationParseException - Exception in org.activemq.spring
An exception that is thrown if a configuration resource could not be parsed.
ConfigurationParseException(Resource, Throwable) - Constructor for exception org.activemq.spring.ConfigurationParseException
 
configure(NetworkChannel) - Method in class org.activemq.transport.NetworkConnector
Performs any network connector based configuration; such as setting the dispatch policies
configureChannel() - Method in class org.activemq.transport.composite.CompositeTransportChannel
 
configureChannel() - Method in class org.activemq.transport.reliable.ReliableTransportChannel
 
connect() - Method in class org.activemq.transport.multicast.MulticastTransportChannel
 
CONNECT - Static variable in interface org.activemq.transport.stomp.Stomp.Commands
 
connect() - Method in class org.activemq.transport.udp.UdpTransportChannel
 
connect(BrokerConnector) - Method in class org.activemq.transport.vm.VmTransportChannel
Connects the client side transport channel with the broker
CONNECT_ACTION - Static variable in class org.activemq.security.jassjacc.JMSBrokerPermission
 
CONNECTED - Static variable in interface org.activemq.transport.stomp.Stomp.Responses
 
CONNECTED - Static variable in class org.activemq.transport.TransportStatusEvent
The channel has been intially and successfully connected
connection - Variable in class org.activemq.ActiveMQSession
 
CONNECTION_ADVISORY_PREFIX - Static variable in class org.activemq.message.ActiveMQDestination
prefix for connection advisory destinations
ConnectionAdvisor - Class in org.activemq.advisories
A helper class for listening for MessageConnection advisories *
ConnectionAdvisor(Connection) - Constructor for class org.activemq.advisories.ConnectionAdvisor
Construct a ConnectionAdvisor
ConnectionAdvisoryEvent - Class in org.activemq.advisories
This event is raised when a MessageConnection starts/stops * @version $Revision: 1.1.1.1 $
ConnectionAdvisoryEventListener - Interface in org.activemq.advisories
A Listener for ConnectionAdvisoryEvents * @version $Revision: 1.1.1.1 $
ConnectionClosedException - Exception in org.activemq
An exception thrown when attempt is made to use a connection when the connection has been closed.
ConnectionClosedException() - Constructor for exception org.activemq.ConnectionClosedException
 
ConnectionInfo - Class in org.activemq.message
Describes a Connection
ConnectionInfo() - Constructor for class org.activemq.message.ConnectionInfo
 
connectionInfoReader - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
ConnectionInfoReader - Class in org.activemq.io.impl
Reads a ConnnectionInfo object from a Stream
ConnectionInfoReader() - Constructor for class org.activemq.io.impl.ConnectionInfoReader
 
connectionInfoWriter - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
ConnectionInfoWriter - Class in org.activemq.io.impl
Writes a ConsumerInfo object to a Stream
ConnectionInfoWriter() - Constructor for class org.activemq.io.impl.ConnectionInfoWriter
 
ConnectionKey - Class in org.activemq.pool
A cache key for the connection details
ConnectionKey(String, String) - Constructor for class org.activemq.pool.ConnectionKey
 
ConstantExpression - Class in org.activemq.filter
Represents a constant expression
ConstantExpression(Object) - Constructor for class org.activemq.filter.ConstantExpression
 
consume(Packet) - Method in class org.activemq.ActiveMQConnection
Implementation of the PacketListener interface - consume a packet
consume(Packet) - Method in class org.activemq.broker.impl.BrokerClientImpl
Consume a Packet from the underlying TransportChannel for processing
consume(Packet) - Method in interface org.activemq.message.PacketListener
Consume a Packet
consume(Packet) - Method in class org.activemq.transport.multicast.MulticastDiscoveryAgent
Consume multicast packets
consume(Packet) - Method in class org.activemq.transport.multicast.MulticastTester
 
consume(Packet) - Method in class org.activemq.transport.reliable.ReliableTransportChannel
consume a packet from the enbedded channel
CONSUME_ACTION - Static variable in class org.activemq.security.jassjacc.JMSDestinationPermission
 
consumeConnectionInfo(ConnectionInfo) - Method in class org.activemq.broker.impl.BrokerClientImpl
register with the Broker
consumeConsumerInfo(ConsumerInfo) - Method in class org.activemq.broker.impl.BrokerClientImpl
Register/deregister MessageConsumer with the Broker
CONSUMER_ADVISORY_PREFIX - Static variable in class org.activemq.message.ActiveMQDestination
Deprecated. Use #getDestinationForConsumerAdvisory() instead.
CONSUMER_DISPATCH_ASYNC - Static variable in class org.activemq.ActiveMQSession
 
CONSUMER_DISPATCH_SYNC - Static variable in class org.activemq.ActiveMQSession
 
CONSUMER_DISPATCH_UNSET - Static variable in class org.activemq.ActiveMQSession
 
CONSUMER_INFO - Static variable in interface org.activemq.message.Packet
Consumer Infomation
ConsumerAdvisor - Class in org.activemq.advisories
A helper class for listening for MessageConsumer advisories
ConsumerAdvisor(Connection, Destination) - Constructor for class org.activemq.advisories.ConsumerAdvisor
Construct a ConsumerAdvisor
ConsumerAdvisoryEvent - Class in org.activemq.advisories
This event is raised when a MessageConsumer starts/stops * @version $Revision: 1.1.1.1 $
ConsumerAdvisoryEventListener - Interface in org.activemq.advisories
A Listener for ConsumerAdvisoryEvents * @version $Revision: 1.1.1.1 $
consumerIdentifier - Variable in class org.activemq.ActiveMQMessageConsumer
 
ConsumerInfo - Class in org.activemq.message
Describes a Message consumer
ConsumerInfo() - Constructor for class org.activemq.message.ConsumerInfo
 
consumerInfo - Variable in class org.activemq.service.boundedvm.DurableSubscription
 
consumerInfo - Variable in class org.activemq.service.boundedvm.TransientSubscription
 
ConsumerInfoListener - Interface in org.activemq.broker
A listener for ConsumerInfo packets
consumerInfoReader - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
ConsumerInfoReader - Class in org.activemq.io.impl
Reads a ConsumerInfo object from a Stream
ConsumerInfoReader() - Constructor for class org.activemq.io.impl.ConsumerInfoReader
 
consumerInfoWriter - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
ConsumerInfoWriter - Class in org.activemq.io.impl
Writes a ConsumerInfo object to a Stream
ConsumerInfoWriter() - Constructor for class org.activemq.io.impl.ConsumerInfoWriter
 
consumerName - Variable in class org.activemq.ActiveMQMessageConsumer
 
consumerNumber - Variable in class org.activemq.ActiveMQMessageConsumer
 
consumers - Variable in class org.activemq.ActiveMQSession
 
containerNameDataType - Variable in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
containerShutdown() - Method in class org.activemq.broker.impl.BrokerContainerImpl
Causes a clean shutdown of the container when the VM is being shut down
contains(Object) - Method in class org.activemq.service.impl.DefaultQueueList
 
contains(Object) - Method in class org.activemq.service.impl.QueueListSupport
 
contains(Object) - Method in interface org.activemq.service.QueueList
Returns true if this list contains the specified element.
containsMessage(MessageIdentity) - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
 
containsMessage(MessageIdentity) - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
 
containsMessage(MessageIdentity) - Method in class org.activemq.service.impl.DurableQueueMessageContainer
 
containsMessage(MessageIdentity) - Method in class org.activemq.service.impl.DurableTopicMessageContainer
 
containsMessage(MessageIdentity) - Method in interface org.activemq.service.MessageContainer
Returns whether or not this container contains the given message identity which provides an optimisation over getMessage() where the message does not need to be loaded.
CONTENT_LENGTH - Static variable in interface org.activemq.transport.stomp.Stomp.Headers
 
convertBodyToBytes() - Method in class org.activemq.message.ActiveMQMessage
Convert the message body to data
copy() - Method in class org.activemq.io.impl.AbstractDefaultWireFormat
 
copy() - Method in class org.activemq.io.impl.DefaultWireFormat
 
copy() - Method in class org.activemq.io.impl.StatelessDefaultWireFormat
 
copy() - Method in class org.activemq.io.util.ByteArray
make a copy
copy() - Method in interface org.activemq.io.WireFormat
Creates a new copy of this wire format so it can be used in another thread/context
copy() - Method in class org.activemq.transport.jabber.JabberWireFormat
 
copy() - Method in class org.activemq.transport.stomp.StompWireFormat
Creates a new copy of this wire format so it can be used in another thread/context
copyMessageOnSend - Variable in class org.activemq.ActiveMQConnectionFactory
 
CORRELATION_ID - Static variable in interface org.activemq.transport.stomp.Stomp.Headers.Message
 
CORRELATION_ID - Static variable in interface org.activemq.transport.stomp.Stomp.Headers.Send
 
CORRELATION_INDEX - Static variable in class org.activemq.message.ActiveMQMessage
Message flag indexes (used for writing/reading to/from a Stream
CountStatisticImpl - Class in org.activemq.management
A count statistic implementation
CountStatisticImpl(CountStatisticImpl, String, String) - Constructor for class org.activemq.management.CountStatisticImpl
 
CountStatisticImpl(String, String) - Constructor for class org.activemq.management.CountStatisticImpl
 
CountStatisticImpl(String, String, String) - Constructor for class org.activemq.management.CountStatisticImpl
 
create(WireFormat, URI) - Method in class org.activemq.transport.activeio.ActiveIOTransportChannelFactory
Create a Channel to a remote Node - e.g.
create(WireFormat, URI, URI) - Method in class org.activemq.transport.activeio.ActiveIOTransportChannelFactory
Create a Channel to a remote Node - e.g.
create(WireFormat, URI) - Method in class org.activemq.transport.activeio.ActiveIOTransportServerChannelFactory
Bind a ServerChannel to an address O
create(WireFormat, URI) - Method in class org.activemq.transport.composite.CompositeTransportChannelFactory
 
create(WireFormat, URI, URI) - Method in class org.activemq.transport.composite.CompositeTransportChannelFactory
 
create(WireFormat, URI) - Method in class org.activemq.transport.DiscoveryTransportChannelFactorySupport
 
create(WireFormat, URI) - Method in class org.activemq.transport.jabber.JabberTransportChannelFactory
 
create(WireFormat, URI, URI) - Method in class org.activemq.transport.jabber.JabberTransportChannelFactory
 
create(WireFormat, URI) - Method in class org.activemq.transport.jabber.JabberTransportServerChannelFactory
 
create(WireFormat, URI) - Method in class org.activemq.transport.multicast.MulticastTransportChannelFactory
Create a Channel to a remote Node - e.g.
create(WireFormat, URI, URI) - Method in class org.activemq.transport.multicast.MulticastTransportChannelFactory
Create a Channel to a remote Node - e.g.
create(WireFormat, URI) - Method in class org.activemq.transport.multicast.MulticastTransportServerChannelFactory
Bind a ServerChannel to an address
create(WireFormat, URI) - Method in class org.activemq.transport.peer.PeerTransportChannelFactory
Create a Channel
create(WireFormat, URI, URI) - Method in class org.activemq.transport.peer.PeerTransportChannelFactory
Create a peer channel
create(WireFormat, URI) - Method in class org.activemq.transport.reliable.ReliableTransportChannelFactory
Create a TransportChannel
create(WireFormat, URI) - Method in class org.activemq.transport.remote.RemoteTransportChannelFactory
Create a Channel
create(WireFormat, URI, URI) - Method in class org.activemq.transport.remote.RemoteTransportChannelFactory
Create a peer channel
create(WireFormat, URI) - Method in class org.activemq.transport.stomp.StompTransportChannelFactory
 
create(WireFormat, URI, URI) - Method in class org.activemq.transport.stomp.StompTransportChannelFactory
 
create(WireFormat, URI) - Method in class org.activemq.transport.stomp.StompTransportServerChannelFactory
 
create(WireFormat, URI) - Method in class org.activemq.transport.tcp.SfTransportChannelFactory
Create a Channel to a remote Node - e.g.
create(WireFormat, URI, URI) - Method in class org.activemq.transport.tcp.SfTransportChannelFactory
Create a Channel to a remote Node - e.g.
create(WireFormat, URI) - Method in class org.activemq.transport.tcp.SfTransportServerChannelFactory
Bind a ServerChannel to an address
create(WireFormat, URI) - Method in class org.activemq.transport.tcp.TcpTransportChannelFactory
Create a Channel to a remote Node - e.g.
create(WireFormat, URI, URI) - Method in class org.activemq.transport.tcp.TcpTransportChannelFactory
Create a Channel to a remote Node - e.g.
create(WireFormat, URI) - Method in class org.activemq.transport.tcp.TcpTransportServerChannelFactory
Bind a ServerChannel to an address
create(WireFormat, URI) - Method in interface org.activemq.transport.TransportChannelFactory
Create a Channel to a remote Node - e.g.
create(WireFormat, URI, URI) - Method in interface org.activemq.transport.TransportChannelFactory
Create a Channel to a remote Node - e.g.
create(WireFormat, URI) - Static method in class org.activemq.transport.TransportChannelProvider
Create a Channel to a remote Node - e.g.
create(WireFormat, URI, URI) - Static method in class org.activemq.transport.TransportChannelProvider
Create a Channel to a remote Node - e.g.
create(WireFormat, URI) - Method in interface org.activemq.transport.TransportServerChannelFactory
Bind a ServerChannel to an address
create(WireFormat, URI) - Static method in class org.activemq.transport.TransportServerChannelProvider
Create a Channel used for the Broker to listen to remove connections
create(WireFormat, URI) - Method in class org.activemq.transport.udp.UdpTransportChannelFactory
Create a Channel to a remote Node - e.g.
create(WireFormat, URI, URI) - Method in class org.activemq.transport.udp.UdpTransportChannelFactory
Create a Channel to a remote Node - e.g.
create(WireFormat, URI) - Method in class org.activemq.transport.udp.UdpTransportServerChannelFactory
Bind a ServerChannel to an address
create(WireFormat, URI) - Method in class org.activemq.transport.vm.VmTransportChannelFactory
Create a Channel to a remote Node - e.g.
create(WireFormat, URI, URI) - Method in class org.activemq.transport.vm.VmTransportChannelFactory
Create a Channel to a remote Node - e.g.
create(WireFormat, URI) - Method in class org.activemq.transport.vm.VmTransportServerChannelFactory
Bind a ServerChannel to an address
CREATE_DESTINATION - Static variable in class org.activemq.message.BrokerAdminCommand
 
CREATE_DESTINATION_ACTION - Static variable in class org.activemq.security.jassjacc.JMSBrokerPermission
 
createActiveMQXAConnection(String, String) - Method in class org.activemq.ActiveMQXAConnectionFactory
 
createAND(BooleanExpression, BooleanExpression) - Static method in class org.activemq.filter.LogicExpression
 
createBetween(Expression, Expression, Expression) - Static method in class org.activemq.filter.ComparisonExpression
 
createBooleanCast(Expression) - Static method in class org.activemq.filter.UnaryExpression
 
createBrokerConnector(String) - Method in class org.activemq.ActiveMQConnectionFactory
 
createBrokerContainer(String, BrokerContext) - Method in interface org.activemq.broker.BrokerContainerFactory
Creates a broker container with the given name
createBrokerContainer(String, BrokerContext) - Method in class org.activemq.broker.impl.BrokerContainerFactoryImpl
 
createBrokerContainer(String, BrokerContext) - Method in class org.activemq.spring.SpringBrokerContainerFactory
 
createBrokerContainerFactory() - Method in class org.activemq.ActiveMQConnectionFactory
 
createBrokerContainerFactory(String) - Static method in class org.activemq.XmlConfigHelper
Creates an instance of the broker factory which uses the Spring XML configuration file mechanism.
createBrowser(Queue) - Method in class org.activemq.ActiveMQQueueSession
 
createBrowser(Queue, String) - Method in class org.activemq.ActiveMQQueueSession
 
createBrowser(Queue) - Method in class org.activemq.ActiveMQSession
Creates a QueueBrowser object to peek at the messages on the specified queue.
createBrowser(Queue, String) - Method in class org.activemq.ActiveMQSession
Creates a QueueBrowser object to peek at the messages on the specified queue using a message selector.
createBrowser(Queue) - Method in class org.activemq.ActiveMQTopicSession
 
createBrowser(Queue, String) - Method in class org.activemq.ActiveMQTopicSession
 
createBrowser(Queue) - Method in class org.activemq.pool.PooledSession
 
createBrowser(Queue, String) - Method in class org.activemq.pool.PooledSession
 
createBytesMessage() - Method in class org.activemq.ActiveMQQueueSession
 
createBytesMessage() - Method in class org.activemq.ActiveMQSession
Creates a BytesMessage object.
createBytesMessage() - Method in class org.activemq.ActiveMQTopicSession
 
createBytesMessage() - Method in class org.activemq.pool.PooledSession
 
createChannel(int) - Method in class org.activemq.transport.vm.VmTransportChannel
 
createChildNode() - Method in class org.activemq.filter.DestinationMapNode
Factory method to create a child node
createConnection() - Method in class org.activemq.ActiveMQConnectionFactory
Create a JMS Connection
createConnection(String, String) - Method in class org.activemq.ActiveMQConnectionFactory
 
createConnection() - Method in class org.activemq.ActiveMQXAConnectionFactory
 
createConnection(String, String) - Method in class org.activemq.ActiveMQXAConnectionFactory
 
createConnection() - Method in class org.activemq.pool.PooledConnectionFactory
 
createConnection(String, String) - Method in class org.activemq.pool.PooledConnectionFactory
 
createConnection(ConnectionKey) - Method in class org.activemq.pool.PooledConnectionFactory
 
createConnection() - Method in class org.activemq.util.JmsLogAppender
 
createConnection() - Method in class org.activemq.util.JmsLogAppenderSupport
 
createConnection() - Method in class org.activemq.util.JndiJmsLogAppender
 
createConnectionConsumer(Destination, String, ServerSessionPool, int) - Method in class org.activemq.ActiveMQConnection
Creates a connection consumer for this connection (optional operation).
createConnectionConsumer(Destination, String, ServerSessionPool, int, boolean) - Method in class org.activemq.ActiveMQConnection
Creates a connection consumer for this connection (optional operation).
createConnectionConsumer(Topic, String, ServerSessionPool, int) - Method in class org.activemq.ActiveMQConnection
Creates a connection consumer for this connection (optional operation).
createConnectionConsumer(Queue, String, ServerSessionPool, int) - Method in class org.activemq.ActiveMQConnection
Creates a connection consumer for this connection (optional operation).
createConnectionConsumer(Destination, String, ServerSessionPool, int) - Method in class org.activemq.pool.PooledConnection
 
createConnectionConsumer(Topic, String, ServerSessionPool, int) - Method in class org.activemq.pool.PooledConnection
 
createConnectionConsumer(Queue, String, ServerSessionPool, int) - Method in class org.activemq.pool.PooledConnection
 
createConnectionFactory(Hashtable) - Method in class org.activemq.jndi.ActiveMQInitialContextFactory
Factory method to create a new connection factory from the given environment
createConnectionInfo() - Method in class org.activemq.transport.jabber.JabberWireFormat
 
createConsumer(Destination) - Method in class org.activemq.ActiveMQQueueSession
 
createConsumer(Destination, String) - Method in class org.activemq.ActiveMQQueueSession
 
createConsumer(Destination, String, boolean) - Method in class org.activemq.ActiveMQQueueSession
 
createConsumer(Destination) - Method in class org.activemq.ActiveMQSession
Creates a MessageConsumer for the specified destination.
createConsumer(Destination, String) - Method in class org.activemq.ActiveMQSession
Creates a MessageConsumer for the specified destination, using a message selector.
createConsumer(Destination, String, boolean) - Method in class org.activemq.ActiveMQSession
Creates MessageConsumer for the specified destination, using a message selector.
createConsumer(Destination) - Method in class org.activemq.ActiveMQTopicSession
 
createConsumer(Destination, String) - Method in class org.activemq.ActiveMQTopicSession
 
createConsumer(Destination, String, boolean) - Method in class org.activemq.ActiveMQTopicSession
 
createConsumer(Destination) - Method in class org.activemq.pool.PooledSession
 
createConsumer(Destination, String) - Method in class org.activemq.pool.PooledSession
 
createConsumer(Destination, String, boolean) - Method in class org.activemq.pool.PooledSession
 
createConsumerInfo(ActiveMQMessageConsumer) - Method in class org.activemq.ActiveMQSession
 
createConsumerPacket() - Method in class org.activemq.transport.jabber.JabberWireFormat
 
createContainer(String) - Method in class org.activemq.service.impl.DurableQueueMessageContainerManager
 
createContainer(String) - Method in class org.activemq.service.impl.DurableTopicMessageContainerManager
 
createContainer(String) - Method in class org.activemq.service.impl.MessageContainerManagerSupport
Factory method to create a new MessageContainer
createContainerManagers() - Method in class org.activemq.broker.impl.DefaultBroker
Factory method to create the default container managers
createDatagramPacket() - Method in class org.activemq.transport.udp.UdpTransportChannel
 
createDatagramPacket(Packet) - Method in class org.activemq.transport.udp.UdpTransportChannel
 
createDeadLetterMessage(String, ActiveMQMessage) - Method in class org.activemq.service.DeadLetterPolicy
 
createDestination(int, String) - Static method in class org.activemq.message.ActiveMQDestination
Create a Destination
createDestination(String) - Method in class org.activemq.message.ActiveMQDestination
Factory method to create a child destination if this destination is a composite
createDestination(String) - Method in class org.activemq.message.ActiveMQQueue
 
createDestination(String) - Method in class org.activemq.message.ActiveMQTopic
 
createDestination(String) - Method in class org.activemq.service.impl.DurableQueueMessageContainerManager
 
createDestination(String) - Method in class org.activemq.service.impl.DurableTopicMessageContainerManager
 
createDestination(String) - Method in class org.activemq.service.impl.MessageContainerManagerSupport
Factory method to create a new Destination
createDestination(String, String) - Method in class org.activemq.transport.jabber.JabberWireFormat
 
createDestinationStats() - Method in class org.activemq.message.ActiveMQDestination
Factory method to create a statistics counter object
createDestinationStats() - Method in class org.activemq.message.ActiveMQQueue
 
createDestinationStats() - Method in class org.activemq.message.ActiveMQTopic
 
createDiscoveryAgent(URI) - Method in class org.activemq.transport.DiscoveryTransportChannelFactorySupport
 
createDiscoveryAgent(URI) - Method in class org.activemq.transport.multicast.MulticastDiscoveryTransportChannelFactory
 
createDivide(Expression, Expression) - Static method in class org.activemq.filter.ArithmeticExpression
 
createDurableConnectionConsumer(Topic, String, String, ServerSessionPool, int) - Method in class org.activemq.ActiveMQConnection
Create a durable connection consumer for this connection (optional operation).
createDurableConnectionConsumer(Topic, String, String, ServerSessionPool, int, boolean) - Method in class org.activemq.ActiveMQConnection
Create a durable connection consumer for this connection (optional operation).
createDurableConnectionConsumer(Topic, String, String, ServerSessionPool, int) - Method in class org.activemq.pool.PooledConnection
 
createDurableSubscriber(Topic, String) - Method in class org.activemq.ActiveMQQueueSession
 
createDurableSubscriber(Topic, String, String, boolean) - Method in class org.activemq.ActiveMQQueueSession
 
createDurableSubscriber(Topic, String) - Method in class org.activemq.ActiveMQSession
Creates a durable subscriber to the specified topic.
createDurableSubscriber(Topic, String, String, boolean) - Method in class org.activemq.ActiveMQSession
Creates a durable subscriber to the specified topic, using a message selector and specifying whether messages published by its own connection should be delivered to it.
createDurableSubscriber(Topic, String) - Method in class org.activemq.ActiveMQTopicSession
 
createDurableSubscriber(Topic, String, String, boolean) - Method in class org.activemq.ActiveMQTopicSession
 
createDurableSubscriber(Topic, String) - Method in class org.activemq.pool.PooledSession
 
createDurableSubscriber(Topic, String, String, boolean) - Method in class org.activemq.pool.PooledSession
 
createEntityResolver() - Method in class org.activemq.spring.ActiveMQBeanDefinitionReader
 
createEntry(String) - Method in class org.activemq.jndi.LazyCreateContext
 
createEqual(Expression, Expression) - Static method in class org.activemq.filter.ComparisonExpression
 
createFailedToBuildBodyException(IOException) - Method in class org.activemq.message.ActiveMQObjectMessage
 
createFilter(Destination, String) - Method in interface org.activemq.filter.FilterFactory
 
createFilter(Destination, String) - Method in class org.activemq.filter.FilterFactoryImpl
 
createFilter(ConsumerInfo) - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageManager
Create filter for a Consumer
createFilter(ConsumerInfo) - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageManager
Create filter for a Consumer
createFilter(ConsumerInfo) - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageManager
Create filter for a Consumer
createFilter(ConsumerInfo) - Method in class org.activemq.service.impl.DurableQueueMessageContainerManager
Create filter for a Consumer
createFilter(ConsumerInfo) - Method in class org.activemq.service.impl.DurableTopicMessageContainerManager
Create filter for a Consumer
createFloat(String) - Static method in class org.activemq.filter.ConstantExpression
 
createFromDecimal(String) - Static method in class org.activemq.filter.ConstantExpression
 
createFromHex(String) - Static method in class org.activemq.filter.ConstantExpression
 
createFromOctal(String) - Static method in class org.activemq.filter.ConstantExpression
 
createGreaterThan(Expression, Expression) - Static method in class org.activemq.filter.ComparisonExpression
 
createGreaterThanEqual(Expression, Expression) - Static method in class org.activemq.filter.ComparisonExpression
 
createInExpression(PropertyExpression, List, boolean) - Static method in class org.activemq.filter.UnaryExpression
 
createInFilter(Expression, List) - Static method in class org.activemq.filter.ComparisonExpression
 
createInitialContext() - Method in class org.activemq.util.JndiJmsLogAppender
 
createInstantiateAdapterException(String, Throwable) - Method in class org.activemq.broker.impl.DefaultBroker
 
createIsNotNull(Expression) - Static method in class org.activemq.filter.ComparisonExpression
 
createIsNull(Expression) - Static method in class org.activemq.filter.ComparisonExpression
 
createJMSexception(String, Exception) - Static method in class org.activemq.io.WireFormatLoader
 
createJMSexception(String, Exception) - Static method in class org.activemq.transport.TransportChannelProvider
 
createJMSexception(String, Exception) - Static method in class org.activemq.transport.TransportServerChannelProvider
 
createJournal() - Method in class org.activemq.store.journal.JournalPersistenceAdapter
 
createKey(QueueListSupport.Header) - Method in class org.activemq.service.impl.QueueListSupport
 
createLessThan(Expression, Expression) - Static method in class org.activemq.filter.ComparisonExpression
 
createLessThanEqual(Expression, Expression) - Static method in class org.activemq.filter.ComparisonExpression
 
createLike(Expression, String, String) - Static method in class org.activemq.filter.ComparisonExpression
 
createLocalDiscoveryDetails() - Method in class org.activemq.broker.impl.BrokerContainerImpl
 
createLocalTransaction(BrokerClient, String) - Method in class org.activemq.service.impl.TransactionManagerImpl
 
createLocalTransaction(BrokerClient, String) - Method in class org.activemq.service.TransactionManager
 
createMapMessage() - Method in class org.activemq.ActiveMQQueueSession
 
createMapMessage() - Method in class org.activemq.ActiveMQSession
Creates a MapMessage object.
createMapMessage() - Method in class org.activemq.ActiveMQTopicSession
 
createMapMessage() - Method in class org.activemq.pool.PooledSession
 
createMessage() - Method in class org.activemq.ActiveMQQueueSession
 
createMessage() - Method in class org.activemq.ActiveMQSession
Creates a Message object.
createMessage() - Method in class org.activemq.ActiveMQTopicSession
 
createMessage() - Method in class org.activemq.pool.PooledSession
 
createMessage(LoggingEvent) - Method in class org.activemq.util.JmsLogAppenderSupport
 
createMessageCache(String) - Method in class org.activemq.store.cache.CachePersistenceAdapter
Subclasses should override this method to change the type of MessageCache that is used to cache messages.
createMessageCache(String) - Method in class org.activemq.store.cache.MemoryBoundedCachePersistenceAdapter
 
createMessageCache(String) - Method in class org.activemq.store.cache.SimpleCachePersistenceAdapter
 
createMessageContainer(ActiveMQDestination) - Method in interface org.activemq.broker.BrokerAdmin
 
createMessageContainer(ActiveMQDestination) - Method in class org.activemq.broker.impl.DefaultBroker
 
createMessageContainer(ActiveMQDestination) - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageManager
 
createMessageContainer(ActiveMQDestination) - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageManager
 
createMessageContainer(ActiveMQDestination) - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageManager
 
createMessageContainer(ActiveMQDestination) - Method in class org.activemq.service.impl.DurableQueueMessageContainerManager
 
createMessageContainer(ActiveMQDestination) - Method in class org.activemq.service.impl.DurableTopicMessageContainerManager
 
createMessageContainer(ActiveMQDestination) - Method in class org.activemq.service.impl.MessageContainerManagerSupport
 
createMessageContainer(ActiveMQDestination) - Method in class org.activemq.service.impl.ProxyMessageContainerManager
 
createMessageContainer(ActiveMQDestination) - Method in interface org.activemq.service.MessageContainerManager
Creates a destination.
createMinus(Expression, Expression) - Static method in class org.activemq.filter.ArithmeticExpression
 
createMod(Expression, Expression) - Static method in class org.activemq.filter.ArithmeticExpression
 
createMulticastClientID() - Method in class org.activemq.ActiveMQConnectionFactory
Creates the clientID for the multicast client (used to dispatch local messages over a multicast bus)
createMultiply(Expression, Expression) - Static method in class org.activemq.filter.ArithmeticExpression
 
createNegate(Expression) - Static method in class org.activemq.filter.UnaryExpression
 
createNetworkChannel(String) - Method in class org.activemq.transport.NetworkConnector
Create a channel from the url
createNetworkChannel(String) - Method in class org.activemq.transport.RemoteNetworkConnector
Create a channel from the url
createNetworkConnector(BrokerContainer) - Method in class org.activemq.transport.peer.PeerTransportChannel
Create a NetworkConnector
createNode() - Method in class org.activemq.service.impl.QueueListSupport
 
createNOT(BooleanExpression) - Static method in class org.activemq.filter.UnaryExpression
 
createNotBetween(Expression, Expression, Expression) - Static method in class org.activemq.filter.ComparisonExpression
 
createNotEqual(Expression, Expression) - Static method in class org.activemq.filter.ComparisonExpression
 
createNotInFilter(Expression, List) - Static method in class org.activemq.filter.ComparisonExpression
 
createNotLike(Expression, String, String) - Static method in class org.activemq.filter.ComparisonExpression
 
createObjectMessage() - Method in class org.activemq.ActiveMQQueueSession
 
createObjectMessage(Serializable) - Method in class org.activemq.ActiveMQQueueSession
 
createObjectMessage() - Method in class org.activemq.ActiveMQSession
Creates an ObjectMessage object.
createObjectMessage(Serializable) - Method in class org.activemq.ActiveMQSession
Creates an initialized ObjectMessage object.
createObjectMessage() - Method in class org.activemq.ActiveMQTopicSession
 
createObjectMessage(Serializable) - Method in class org.activemq.ActiveMQTopicSession
 
createObjectMessage() - Method in class org.activemq.pool.PooledSession
 
createObjectMessage(Serializable) - Method in class org.activemq.pool.PooledSession
 
createOR(BooleanExpression, BooleanExpression) - Static method in class org.activemq.filter.LogicExpression
 
createPacket() - Method in class org.activemq.io.impl.ActiveMQBytesMessageReader
 
createPacket() - Method in class org.activemq.io.impl.ActiveMQMapMessageReader
 
createPacket() - Method in class org.activemq.io.impl.ActiveMQMessageReader
 
createPacket() - Method in class org.activemq.io.impl.ActiveMQObjectMessageReader
 
createPacket() - Method in class org.activemq.io.impl.ActiveMQStreamMessageReader
 
createPacket() - Method in class org.activemq.io.impl.ActiveMQTextMessageReader
 
createPacket() - Method in class org.activemq.io.impl.BrokerAdminCommandReader
 
createPacket() - Method in class org.activemq.io.impl.BrokerInfoReader
 
createPacket() - Method in class org.activemq.io.impl.CachedValueReader
 
createPacket() - Method in class org.activemq.io.impl.CapacityInfoReader
 
createPacket() - Method in class org.activemq.io.impl.CapacityInfoRequestReader
 
createPacket() - Method in class org.activemq.io.impl.CleanupConnectionInfoReader
 
createPacket() - Method in class org.activemq.io.impl.ConnectionInfoReader
 
createPacket() - Method in class org.activemq.io.impl.ConsumerInfoReader
 
createPacket() - Method in class org.activemq.io.impl.DurableUnsubscribeReader
 
createPacket() - Method in class org.activemq.io.impl.IntResponseReceiptReader
 
createPacket() - Method in class org.activemq.io.impl.KeepAliveReader
 
createPacket() - Method in class org.activemq.io.impl.MessageAckReader
 
createPacket() - Method in interface org.activemq.io.impl.PacketReader
 
createPacket() - Method in class org.activemq.io.impl.ProducerInfoReader
 
createPacket() - Method in class org.activemq.io.impl.ReceiptReader
 
createPacket() - Method in class org.activemq.io.impl.ResponseReceiptReader
 
createPacket() - Method in class org.activemq.io.impl.SessionInfoReader
 
createPacket() - Method in class org.activemq.io.impl.TransactionInfoReader
 
createPacket() - Method in class org.activemq.io.impl.WireFormatInfoReader
 
createPacket() - Method in class org.activemq.io.impl.XATransactionInfoReader
 
createPacketListenerSender() - Method in class org.activemq.transport.vm.VmTransportChannel
Creates a sender PacketListener which handles any receipts then delegates to the ultimate PacketListener (typically the JMS client)
createPersistenceAdapter() - Method in class org.activemq.broker.impl.DefaultBroker
Factory method to create a default persistence adapter
createPersistenceAdapter(File, MemoryBoundedObjectManager) - Method in class org.activemq.broker.impl.DefaultPersistenceAdapterFactory
Creates a persistence Adapter that can use a given directory to store it's data.
createPersistenceAdapter(File, MemoryBoundedObjectManager) - Method in interface org.activemq.store.PersistenceAdapterFactory
Creates a persistence Adapter that can use a given directory to store it's data.
createPersistenceAdapter(File, MemoryBoundedObjectManager) - Method in class org.activemq.store.vm.VMPersistenceAdapterFactory
Creates a persistence Adapter that can use a given directory to store it's data.
createPlus(Expression, Expression) - Static method in class org.activemq.filter.ArithmeticExpression
 
createProducer(Destination) - Method in class org.activemq.ActiveMQQueueSession
 
createProducer(Destination) - Method in class org.activemq.ActiveMQSession
Creates a MessageProducer to send messages to the specified destination.
createProducer(Destination) - Method in class org.activemq.ActiveMQTopicSession
 
createProducer(Destination) - Method in class org.activemq.pool.PooledSession
 
createProducer() - Method in class org.activemq.util.JmsLogAppenderSupport
 
createProducerInfo(ActiveMQMessageProducer) - Method in class org.activemq.ActiveMQSession
 
createProxy(Class, Object, Executor) - Static method in class org.activemq.util.AsyncProxy
 
createPublisher(Topic) - Method in class org.activemq.ActiveMQSession
Creates a publisher for the specified topic.
createPublisher(Topic) - Method in class org.activemq.ActiveMQTopicSession
 
createPublisher(Topic) - Method in class org.activemq.pool.PooledSession
 
createQueue(String) - Method in class org.activemq.ActiveMQQueueSession
 
createQueue(String) - Method in class org.activemq.ActiveMQSession
Creates a queue identity given a Queue name.
createQueue(String) - Method in class org.activemq.ActiveMQTopicSession
 
createQueue(String) - Method in class org.activemq.jndi.ActiveMQInitialContextFactory
Factory method to create new Queue instances
createQueue(String) - Method in class org.activemq.pool.PooledSession
 
createQueueConnection() - Method in class org.activemq.ActiveMQConnectionFactory
Create a JMS QueueConnection
createQueueConnection(String, String) - Method in class org.activemq.ActiveMQConnectionFactory
 
createQueueConnection() - Method in class org.activemq.ActiveMQXAConnectionFactory
 
createQueueConnection(String, String) - Method in class org.activemq.ActiveMQXAConnectionFactory
 
createQueueMessageStore(String) - Method in class org.activemq.store.cache.CachePersistenceAdapter
 
createQueueMessageStore(String) - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
createQueueMessageStore(String) - Method in class org.activemq.store.journal.JournalPersistenceAdapter
 
createQueueMessageStore(String) - Method in interface org.activemq.store.PersistenceAdapter
Factory method to create a new queue message store with the given destination name
createQueueMessageStore(String) - Method in class org.activemq.store.vm.VMPersistenceAdapter
 
createQueues(Map, Hashtable) - Method in class org.activemq.jndi.ActiveMQInitialContextFactory
 
createQueueSession(boolean, int) - Method in class org.activemq.ActiveMQConnection
Creates a QueueSession object.
createQueueSession(boolean, int) - Method in class org.activemq.pool.PooledConnection
 
createReader(String) - Method in class org.activemq.spring.ActiveMQBeanFactory
A hook to allow custom ActiveMQBeanFactory implementations to provide their own custom parser of the XML to perform macro processing or perform XSLT etc
createReceiver(Queue) - Method in class org.activemq.ActiveMQQueueSession
 
createReceiver(Queue, String) - Method in class org.activemq.ActiveMQQueueSession
 
createReceiver(Queue) - Method in class org.activemq.ActiveMQSession
Creates a QueueReceiver object to receive messages from the specified queue.
createReceiver(Queue, String) - Method in class org.activemq.ActiveMQSession
Creates a QueueReceiver object to receive messages from the specified queue using a message selector.
createReceiver(Queue) - Method in class org.activemq.pool.PooledSession
 
createReceiver(Queue, String) - Method in class org.activemq.pool.PooledSession
 
createRecoveryFailedException(Exception) - Method in class org.activemq.store.journal.JournalPersistenceAdapter
 
createReference(String, JNDIStorableInterface) - Static method in class org.activemq.jndi.JNDIReferenceFactory
Create a Reference instance from a JNDIStorable object
createSender(Queue) - Method in class org.activemq.ActiveMQQueueSession
 
createSender(Queue) - Method in class org.activemq.ActiveMQSession
Creates a QueueSender object to send messages to the specified queue.
createSender(Queue) - Method in class org.activemq.pool.PooledSession
 
createServerSide() - Method in class org.activemq.transport.vm.VmTransportChannel
Creates the server side version of this client side channel.
createServerSocket(URI) - Method in class org.activemq.transport.tcp.SfTransportServerChannelFactory
 
createServerSocket(URI) - Method in class org.activemq.transport.tcp.TcpTransportServerChannel
Factory method to create a new ServerSocket
createSession(boolean, int) - Method in class org.activemq.ActiveMQConnection
Creates a Session object.
createSession(boolean, int, boolean) - Method in class org.activemq.ActiveMQConnection
Creates a Session object.
createSession(boolean, int) - Method in class org.activemq.ActiveMQXAConnection
 
createSession(boolean, int) - Method in class org.activemq.pool.PooledConnection
 
createSession(SessionKey) - Method in class org.activemq.pool.PooledConnection
 
createSession() - Method in class org.activemq.pool.SessionPool
 
createSession() - Method in class org.activemq.util.JmsLogAppenderSupport
 
createSocket(int) - Method in class org.activemq.transport.multicast.MulticastTransportChannel
 
createSocket(URI) - Method in class org.activemq.transport.tcp.SfTransportChannelFactory
 
createSocket(URI, URI) - Method in class org.activemq.transport.tcp.SfTransportChannelFactory
 
createSocket(URI) - Method in class org.activemq.transport.tcp.TcpTransportChannel
Factory method to create a new socket
createSocket(URI, URI) - Method in class org.activemq.transport.tcp.TcpTransportChannel
Factory method to create a new socket
createSocket(int) - Method in class org.activemq.transport.udp.UdpTransportChannel
 
createStatementProvider() - Static method in class org.activemq.store.jdbc.adapter.AxionJDBCAdapter
 
createStatementProvider() - Static method in class org.activemq.store.jdbc.adapter.ImageBasedJDBCAdaptor
 
createStatementProvider() - Static method in class org.activemq.store.jdbc.adapter.InformixJDBCAdapter
 
createStatementProvider() - Static method in class org.activemq.store.jdbc.adapter.OracleJDBCAdapter
 
createStatementProvider() - Static method in class org.activemq.store.jdbc.adapter.PostgresqlJDBCAdapter
 
createStreamMessage() - Method in class org.activemq.ActiveMQQueueSession
 
createStreamMessage() - Method in class org.activemq.ActiveMQSession
Creates a StreamMessage object.
createStreamMessage() - Method in class org.activemq.ActiveMQTopicSession
 
createStreamMessage() - Method in class org.activemq.pool.PooledSession
 
createSubcontext(Name) - Method in class org.activemq.jndi.ReadOnlyContext
 
createSubcontext(String) - Method in class org.activemq.jndi.ReadOnlyContext
 
createSubscriber(Topic) - Method in class org.activemq.ActiveMQSession
Creates a nondurable subscriber to the specified topic.
createSubscriber(Topic, String, boolean) - Method in class org.activemq.ActiveMQSession
Creates a nondurable subscriber to the specified topic, using a message selector or specifying whether messages published by its own connection should be delivered to it.
createSubscriber(Topic) - Method in class org.activemq.ActiveMQTopicSession
 
createSubscriber(Topic, String, boolean) - Method in class org.activemq.ActiveMQTopicSession
 
createSubscriber(Topic) - Method in class org.activemq.pool.PooledSession
 
createSubscriber(Topic, String, boolean) - Method in class org.activemq.pool.PooledSession
 
createSubscription(Dispatcher, BrokerClient, ConsumerInfo, Filter) - Method in class org.activemq.service.impl.DurableTopicSubscriptionContainerImpl
 
createSubscription(Dispatcher, BrokerClient, ConsumerInfo, Filter) - Method in class org.activemq.service.impl.SubscriptionContainerImpl
 
createSubscriptionEntry() - Method in class org.activemq.service.impl.SubscriptionImpl
 
createTemporaryName(String) - Static method in class org.activemq.message.ActiveMQDestination
Create a temporary name from the clientId
createTemporaryQueue() - Method in class org.activemq.ActiveMQQueueSession
 
createTemporaryQueue() - Method in class org.activemq.ActiveMQSession
Creates a TemporaryQueue object.
createTemporaryQueue() - Method in class org.activemq.ActiveMQTopicSession
 
createTemporaryQueue() - Method in class org.activemq.pool.PooledSession
 
createTemporaryTopic() - Method in class org.activemq.ActiveMQQueueSession
 
createTemporaryTopic() - Method in class org.activemq.ActiveMQSession
Creates a TemporaryTopic object.
createTemporaryTopic() - Method in class org.activemq.ActiveMQTopicSession
 
createTemporaryTopic() - Method in class org.activemq.pool.PooledSession
 
createTextMessage() - Method in class org.activemq.ActiveMQQueueSession
 
createTextMessage(String) - Method in class org.activemq.ActiveMQQueueSession
 
createTextMessage() - Method in class org.activemq.ActiveMQSession
Creates a TextMessage object.
createTextMessage(String) - Method in class org.activemq.ActiveMQSession
Creates an initialized TextMessage object.
createTextMessage() - Method in class org.activemq.ActiveMQTopicSession
 
createTextMessage(String) - Method in class org.activemq.ActiveMQTopicSession
 
createTextMessage() - Method in class org.activemq.pool.PooledSession
 
createTextMessage(String) - Method in class org.activemq.pool.PooledSession
 
createTopic(String) - Method in class org.activemq.ActiveMQQueueSession
 
createTopic(String) - Method in class org.activemq.ActiveMQSession
Creates a topic identity given a Topic name.
createTopic(String) - Method in class org.activemq.ActiveMQTopicSession
 
createTopic(String) - Method in class org.activemq.jndi.ActiveMQInitialContextFactory
Factory method to create new Topic instances
createTopic(String) - Method in class org.activemq.pool.PooledSession
 
createTopicConnection() - Method in class org.activemq.ActiveMQConnectionFactory
Create a JMS TopicConnection
createTopicConnection(String, String) - Method in class org.activemq.ActiveMQConnectionFactory
 
createTopicConnection() - Method in class org.activemq.ActiveMQXAConnectionFactory
 
createTopicConnection(String, String) - Method in class org.activemq.ActiveMQXAConnectionFactory
 
createTopicMessageStore(String) - Method in class org.activemq.store.cache.CachePersistenceAdapter
 
createTopicMessageStore(String) - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
createTopicMessageStore(String) - Method in class org.activemq.store.journal.JournalPersistenceAdapter
 
createTopicMessageStore(String) - Method in interface org.activemq.store.PersistenceAdapter
Factory method to create a new topic message store with the given destination name
createTopicMessageStore(String) - Method in class org.activemq.store.vm.VMPersistenceAdapter
 
createTopics(Map, Hashtable) - Method in class org.activemq.jndi.ActiveMQInitialContextFactory
 
createTopicSession(boolean, int) - Method in class org.activemq.ActiveMQConnection
Creates a TopicSession object.
createTopicSession(boolean, int) - Method in class org.activemq.pool.PooledConnection
 
createTransactionStore() - Method in class org.activemq.store.cache.CachePersistenceAdapter
 
createTransactionStore() - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
createTransactionStore() - Method in class org.activemq.store.journal.JournalPersistenceAdapter
 
createTransactionStore() - Method in interface org.activemq.store.PersistenceAdapter
Factory method to create a new persistent prepared transaction store for XA recovery
createTransactionStore() - Method in class org.activemq.store.vm.VMPersistenceAdapter
 
createTransformer(Source) - Static method in class org.activemq.spring.ActiveMQBeanDefinitionReader
 
createTransportChannel(String) - Method in class org.activemq.ActiveMQConnectionFactory
Factory method to create a TransportChannel from a URL
createTransportChannel(Socket, PooledExecutor) - Method in class org.activemq.transport.jabber.JabberTransportServerChannel
 
createTransportChannel(Socket, PooledExecutor) - Method in class org.activemq.transport.stomp.StompTransportServerChannel
 
createTransportChannel(Socket, PooledExecutor) - Method in class org.activemq.transport.tcp.TcpTransportServerChannel
 
createTransportServerChannel(WireFormat, String) - Static method in class org.activemq.broker.impl.BrokerConnectorImpl
Factory method ot create a transport channel
createURI(String, URI) - Method in class org.activemq.ActiveMQConnectionFactory
 
createURI(String) - Method in class org.activemq.ActiveMQConnectionFactory
 
createWriteException(Packet, Exception) - Method in class org.activemq.store.journal.JournalPersistenceAdapter
 
createWriteException(String, Exception) - Method in class org.activemq.store.journal.JournalPersistenceAdapter
 
createXAConnection() - Method in class org.activemq.ActiveMQXAConnectionFactory
 
createXAConnection(String, String) - Method in class org.activemq.ActiveMQXAConnectionFactory
 
createXAQueueConnection() - Method in class org.activemq.ActiveMQXAConnectionFactory
 
createXAQueueConnection(String, String) - Method in class org.activemq.ActiveMQXAConnectionFactory
 
createXAQueueSession() - Method in class org.activemq.ActiveMQXAConnection
 
createXASession() - Method in class org.activemq.ActiveMQXAConnection
 
createXATopicConnection() - Method in class org.activemq.ActiveMQXAConnectionFactory
 
createXATopicConnection(String, String) - Method in class org.activemq.ActiveMQXAConnectionFactory
 
createXATopicSession() - Method in class org.activemq.ActiveMQXAConnection
 
createXATransaction(BrokerClient, ActiveMQXid) - Method in class org.activemq.service.impl.TransactionManagerImpl
 
createXATransaction(BrokerClient, ActiveMQXid) - Method in class org.activemq.service.TransactionManager
 
createXPath(String) - Static method in class org.activemq.filter.UnaryExpression
 
createXQuery(String) - Static method in class org.activemq.filter.UnaryExpression
 
createXslSource() - Method in class org.activemq.spring.ActiveMQBeanDefinitionReader
Creates the XSL resource for the transformation
curChar - Variable in class org.activemq.selector.SelectorParserTokenManager
 
currentToken - Variable in exception org.activemq.selector.ParseException
This is the last token that has been consumed successfully.
currentURI - Variable in class org.activemq.transport.composite.CompositeTransportChannel
 
currentWireFormat - Variable in class org.activemq.transport.TransportChannelSupport
 
currentWireFormatVersion - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 

D

data - Variable in class org.activemq.store.journal.JournalTransactionStore.TxOperation
 
dataIn - Variable in class org.activemq.transport.tcp.TcpTransportChannel
 
dataOut - Variable in class org.activemq.transport.tcp.TcpTransportChannel
 
DEAD_LETTER_PREFIX - Static variable in class org.activemq.service.DeadLetterPolicy
Prefix used by dead letter queues
deadLetterAlreadySent(long, boolean) - Method in class org.activemq.store.cache.CachePersistenceAdapter
Verifies if a dead letter has already been sent for a message
deadLetterAlreadySent(long, boolean) - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
Ensures that no previous dead letter was already sent for this message
deadLetterAlreadySent(long, boolean) - Method in class org.activemq.store.journal.JournalPersistenceAdapter
Verifies if a dead letter has already been sent for a message
deadLetterAlreadySent(long, boolean) - Method in interface org.activemq.store.PersistenceAdapter
Verifies if a dead letter has already been sent for a message
deadLetterAlreadySent(long, boolean) - Method in class org.activemq.store.vm.VMPersistenceAdapter
Verifies if a dead letter has already been sent for a message
DeadLetterPolicy - Class in org.activemq.service
Determines how messages are stored in a dead letter queue
DeadLetterPolicy(Broker) - Constructor for class org.activemq.service.DeadLetterPolicy
Construct a dead letter policy
DeadLetterPolicy(BrokerContainer) - Constructor for class org.activemq.service.DeadLetterPolicy
 
DeadLetterPolicy() - Constructor for class org.activemq.service.DeadLetterPolicy
Default constructor
debugStream - Variable in class org.activemq.selector.SelectorParserTokenManager
 
DECIMAL_LITERAL - Static variable in interface org.activemq.selector.SelectorParserConstants
 
decrement() - Method in class org.activemq.management.CountStatisticImpl
 
decrementConsumerCounter() - Method in class org.activemq.message.ActiveMQDestination
descrement counter for number interested consumers
decrementIndent() - Method in class org.activemq.util.IndentPrinter
 
decrementMemoryReferenceCount() - Method in interface org.activemq.io.util.MemoryManageable
Decrement reference count for bounded memory collections
decrementMemoryReferenceCount() - Method in class org.activemq.message.AbstractPacket
Decrement reference count for bounded memory collections
decrementMemoryReferenceCount() - Method in interface org.activemq.message.Packet
Decrement reference count for bounded memory collections
decrementMemoryReferenceCount() - Method in class org.activemq.service.boundedvm.DurableMessagePointer
 
decrementMemoryUsed(int) - Method in class org.activemq.io.util.MemoryBoundedObjectManager
 
decrementMemoryUsed(MemoryManageable) - Method in class org.activemq.io.util.MemoryBoundedQueue
 
decrementMemoryUsed(int) - Method in class org.activemq.io.util.MemoryBoundedQueueManager
 
decrementMessageCountAndMaybeDelete(MessageIdentity) - Method in class org.activemq.store.cache.CacheTopicMessageStore
 
decrementMessageCountAndMaybeDelete(MessageIdentity) - Method in class org.activemq.store.jdbc.JDBCTopicMessageStore
 
decrementMessageCountAndMaybeDelete(MessageIdentity) - Method in class org.activemq.store.journal.JournalTopicMessageStore
 
decrementMessageCountAndMaybeDelete(MessageIdentity) - Method in class org.activemq.store.ProxyTopicMessageStore
 
decrementMessageCountAndMaybeDelete(MessageIdentity) - Method in interface org.activemq.store.TopicMessageStore
Decrement the reference count of this message ID and if there are no more references then delete the message from persistent store (or maybe archive it off somewhere)
decrementMessageCountAndMaybeDelete(MessageIdentity) - Method in class org.activemq.store.vm.VMTopicMessageStore
 
deepCopy() - Method in class org.activemq.message.ActiveMQBytesMessage
 
deepCopy() - Method in class org.activemq.message.ActiveMQMapMessage
 
deepCopy() - Method in class org.activemq.message.ActiveMQMessage
 
deepCopy() - Method in class org.activemq.message.ActiveMQObjectMessage
 
deepCopy() - Method in class org.activemq.message.ActiveMQStreamMessage
 
deepCopy() - Method in class org.activemq.message.ActiveMQTextMessage
 
DEFAULT - Static variable in interface org.activemq.selector.SelectorParserConstants
 
DEFAULT_BACKLOG - Static variable in class org.activemq.transport.tcp.TcpTransportServerChannel
 
DEFAULT_BROKER_CONNECTOR_URI - Static variable in class org.activemq.transport.peer.PeerTransportChannel
 
DEFAULT_BROKER_URL - Static variable in class org.activemq.ActiveMQConnection
Default URL for the ActiveMQ Broker
DEFAULT_COMPRESSION_LEVEL - Static variable in class org.activemq.io.util.ByteArrayCompression
Default compression level - 0 being none, 9 being best
DEFAULT_COMPRESSION_LIMIT - Static variable in class org.activemq.io.util.ByteArrayCompression
Data size above which compression will be used
DEFAULT_COMPRESSION_STRATEGY - Static variable in class org.activemq.io.util.ByteArrayCompression
Default Compression Strategy
DEFAULT_DISCOVERY_URI - Static variable in class org.activemq.transport.multicast.MulticastDiscoveryAgent
default URI used for discovery
DEFAULT_DISCOVERY_URI - Static variable in class org.activemq.transport.multicast.MulticastTester
 
DEFAULT_FRAGMENTATION_LIMIT - Static variable in class org.activemq.io.util.ByteArrayFragmentation
Data size above which fragmentation will be used
DEFAULT_INITIAL_CAPACITY - Static variable in class org.activemq.util.LRUCache
 
DEFAULT_JOURNAL_TYPE - Static variable in class org.activemq.store.journal.JournalPersistenceAdapter
 
DEFAULT_LOAD_FACTOR - Static variable in class org.activemq.util.LRUCache
 
DEFAULT_MAXIMUM_MESSAGE_SIZE - Static variable in interface org.activemq.io.WireFormat
The maximum message size supported by the transport If the message is bigger than this size, then the message will be 'chunked' into separate pieces and re-assembled on the consumer
DEFAULT_ORDERED_TARGET - Static variable in class org.activemq.message.ActiveMQDestination
The default target for ordered destinations
DEFAULT_PASSWORD - Static variable in class org.activemq.ActiveMQConnection
Default Password for the Connection
DEFAULT_URL - Static variable in class org.activemq.ActiveMQConnection
Default client URL.
DEFAULT_USER - Static variable in class org.activemq.ActiveMQConnection
Default UserName for the Connection
DefaultBroker - Class in org.activemq.broker.impl
The default Broker implementation
DefaultBroker(String, String, MemoryBoundedObjectManager) - Constructor for class org.activemq.broker.impl.DefaultBroker
 
DefaultBroker(String, MemoryBoundedObjectManager) - Constructor for class org.activemq.broker.impl.DefaultBroker
 
DefaultBroker(String, String) - Constructor for class org.activemq.broker.impl.DefaultBroker
 
DefaultBroker(String) - Constructor for class org.activemq.broker.impl.DefaultBroker
 
DefaultBroker(String, String, PersistenceAdapter) - Constructor for class org.activemq.broker.impl.DefaultBroker
 
DefaultBroker(String, PersistenceAdapter) - Constructor for class org.activemq.broker.impl.DefaultBroker
 
DefaultComparator - Class in org.activemq.util
A trivial default Comparator which only works on objects which are Comparable
DefaultComparator() - Constructor for class org.activemq.util.DefaultComparator
 
defaultConnectionFactoryNames - Static variable in class org.activemq.jndi.ActiveMQInitialContextFactory
 
defaultDestination - Variable in class org.activemq.ActiveMQMessageProducer
 
DefaultJDBCAdapter - Class in org.activemq.store.jdbc.adapter
Implements all the default JDBC operations that are used by the JDBCPersistenceAdapter.
DefaultJDBCAdapter(StatementProvider) - Constructor for class org.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
DefaultJDBCAdapter() - Constructor for class org.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
DefaultPersistenceAdapterFactory - Class in org.activemq.broker.impl
Factory class that can create PersistenceAdapter objects.
DefaultPersistenceAdapterFactory() - Constructor for class org.activemq.broker.impl.DefaultPersistenceAdapterFactory
 
DefaultQueueList - Class in org.activemq.service.impl
Linked list class to provide uniformly named methods to get,remove and insert an element at the beginning and end of the list.
DefaultQueueList() - Constructor for class org.activemq.service.impl.DefaultQueueList
Constructs an empty list.
DefaultQueueListEntry - Class in org.activemq.service.impl
Linked list entry class
DefaultStatementProvider - Class in org.activemq.store.jdbc.adapter
 
DefaultStatementProvider() - Constructor for class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
DefaultWireFormat - Class in org.activemq.io.impl
This is a stateful AbstractDefaultWireFormat which implements value caching.
DefaultWireFormat() - Constructor for class org.activemq.io.impl.DefaultWireFormat
Default Constructor
deflate(ByteArray) - Method in class org.activemq.io.util.ByteArrayCompression
Deflate the data in the ByteArray
DelegateCapacityMonitor - Class in org.activemq.capacity
BasicCapacityMonitor implementation
DelegateCapacityMonitor() - Constructor for class org.activemq.capacity.DelegateCapacityMonitor
Construct a DelegateCapacityMonitor
DelegateCapacityMonitor(String, CapacityMonitor) - Constructor for class org.activemq.capacity.DelegateCapacityMonitor
Construct a DelegateCapacityMonitor
delete() - Method in class org.activemq.message.ActiveMQDestination
Used to Deletes a temporary destination.
delete(MessageIdentity, MessageAck) - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
 
delete(MessageIdentity, MessageAck) - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
 
delete(MessageIdentity, MessageAck) - Method in class org.activemq.service.impl.DurableQueueMessageContainer
 
delete(MessageIdentity, MessageAck) - Method in class org.activemq.service.impl.DurableTopicMessageContainer
 
delete(MessageIdentity, MessageAck) - Method in interface org.activemq.service.MessageContainer
Delete a message - if no
deleteSubscription(String, String) - Method in interface org.activemq.broker.Broker
Delete a durable subscriber
deleteSubscription(String, String) - Method in class org.activemq.broker.impl.DefaultBroker
 
deleteSubscription(String, String) - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageManager
Delete a durable subscriber
deleteSubscription(String, String) - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageManager
Delete a durable subscriber
deleteSubscription(String, String) - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageManager
Delete a durable subscriber
deleteSubscription(String, String) - Method in class org.activemq.service.impl.DurableQueueMessageContainerManager
Delete a durable subscriber
deleteSubscription(String) - Method in class org.activemq.service.impl.DurableTopicMessageContainer
 
deleteSubscription(String, String) - Method in class org.activemq.service.impl.DurableTopicMessageContainerManager
Delete a durable subscriber
deleteSubscription(String, String) - Method in class org.activemq.service.impl.ProxyMessageContainerManager
 
deleteSubscription(String, String) - Method in class org.activemq.service.impl.TransientTopicMessageContainerManager
Delete a durable subscriber
deleteSubscription(String, String) - Method in interface org.activemq.service.MessageContainerManager
Delete a durable subscriber
deleteSubscription(String) - Method in class org.activemq.store.cache.CacheTopicMessageStore
 
deleteSubscription(String) - Method in class org.activemq.store.jdbc.JDBCTopicMessageStore
 
deleteSubscription(String) - Method in class org.activemq.store.journal.JournalTopicMessageStore
 
deleteSubscription(String) - Method in class org.activemq.store.ProxyTopicMessageStore
 
deleteSubscription(String) - Method in interface org.activemq.store.TopicMessageStore
 
deleteSubscription(String) - Method in class org.activemq.store.vm.VMTopicMessageStore
 
dequeue() - Method in class org.activemq.io.util.MemoryBoundedPrioritizedQueue
 
dequeue() - Method in class org.activemq.io.util.MemoryBoundedQueue
 
dequeue(long) - Method in class org.activemq.io.util.MemoryBoundedQueue
Dequeues a MemoryManageable from the head of the queue
dequeue() - Method in class org.activemq.io.util.SpooledBoundedActiveMQMessageQueue
 
dequeue(long) - Method in class org.activemq.io.util.SpooledBoundedActiveMQMessageQueue
 
dequeueNoWait() - Method in class org.activemq.io.util.MemoryBoundedPrioritizedQueue
dequeues a MemoryManageable from the head of the queue
dequeueNoWait() - Method in class org.activemq.io.util.MemoryBoundedQueue
dequeues a MemoryManageable from the head of the queue
dequeueNoWait() - Method in class org.activemq.io.util.SpooledBoundedActiveMQMessageQueue
 
deregisterClient(BrokerClient, ConnectionInfo) - Method in interface org.activemq.broker.BrokerConnector
Deregister a Broker Client
deregisterClient(BrokerClient, ConnectionInfo) - Method in class org.activemq.broker.impl.BrokerConnectorImpl
Deregister a Broker Client
deregisterConnection(BrokerClient, ConnectionInfo) - Method in interface org.activemq.broker.BrokerContainer
un-registers a Connection
deregisterConnection(BrokerClient, ConnectionInfo) - Method in class org.activemq.broker.impl.BrokerContainerImpl
un-registers a Connection
deregisterConnector(String) - Method in class org.activemq.broker.BrokerContext
 
deregisterContainer(String, BrokerContainer) - Method in class org.activemq.broker.BrokerContext
 
deregisterMessageConsumer(BrokerClient, ConsumerInfo) - Method in interface org.activemq.broker.BrokerConnector
De-register a MessageConsumer from the Broker
deregisterMessageConsumer(BrokerClient, ConsumerInfo) - Method in interface org.activemq.broker.BrokerContainer
De-register a MessageConsumer from the Broker
deregisterMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.activemq.broker.impl.BrokerConnectorImpl
De-register a MessageConsumer from the Broker
deregisterMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.activemq.broker.impl.BrokerContainerImpl
De-register a MessageConsumer from the Broker
deregisterMessageProducer(BrokerClient, ProducerInfo) - Method in interface org.activemq.broker.BrokerConnector
De-register a MessageProducer from the Broker
deregisterMessageProducer(BrokerClient, ProducerInfo) - Method in interface org.activemq.broker.BrokerContainer
De-register a MessageProducer from the Broker
deregisterMessageProducer(BrokerClient, ProducerInfo) - Method in class org.activemq.broker.impl.BrokerConnectorImpl
De-register a MessageProducer from the Broker
deregisterMessageProducer(BrokerClient, ProducerInfo) - Method in class org.activemq.broker.impl.BrokerContainerImpl
De-register a MessageProducer from the Broker
deregisterRemoteClientID(String) - Method in interface org.activemq.broker.BrokerContainer
deregister a remote clientID
deregisterRemoteClientID(String) - Method in class org.activemq.broker.impl.BrokerContainerImpl
deregister a remote clientID
deregisterSession(BrokerClient, SessionInfo) - Method in interface org.activemq.broker.BrokerConnector
De-register a client-side Session from the Broker (used for monitoring)
deregisterSession(BrokerClient, SessionInfo) - Method in interface org.activemq.broker.BrokerContainer
De-register a client-side Session from the Broker (used for monitoring)
deregisterSession(BrokerClient, SessionInfo) - Method in class org.activemq.broker.impl.BrokerConnectorImpl
De-register a client-side Session from the Broker (used for monitoring)
deregisterSession(BrokerClient, SessionInfo) - Method in class org.activemq.broker.impl.BrokerContainerImpl
De-register a client-side Session from the Broker (used for monitoring)
destination - Variable in class org.activemq.ActiveMQMessageConsumer
 
DESTINATION - Static variable in interface org.activemq.transport.stomp.Stomp.Headers.Message
 
DESTINATION - Static variable in interface org.activemq.transport.stomp.Stomp.Headers.Send
 
DESTINATION - Static variable in interface org.activemq.transport.stomp.Stomp.Headers.Subscribe
 
DESTINATION - Static variable in interface org.activemq.transport.stomp.Stomp.Headers.Unsubscribe
 
DestinationFilter - Class in org.activemq.filter
Represents a filter which only operates on Destinations
DestinationFilter() - Constructor for class org.activemq.filter.DestinationFilter
 
DestinationMap - Class in org.activemq.filter
A Map-like data structure allowing values to be indexed by ActiveMQDestination and retrieved by destination - supporting both * and > style of wildcard as well as composite destinations.
DestinationMap() - Constructor for class org.activemq.filter.DestinationMap
 
destinationMap - Variable in class org.activemq.service.impl.DurableQueueMessageContainerManager
 
DestinationMapNode - Class in org.activemq.filter
An implementation class used to implement DestinationMap
DestinationMapNode() - Constructor for class org.activemq.filter.DestinationMapNode
 
destinationName - Variable in class org.activemq.store.jdbc.JDBCMessageStore
 
destinationName - Variable in class org.activemq.store.journal.JournalMessageStore
 
DestinationPath - Class in org.activemq.filter
Helper class for decomposing a Destination into a number of paths
DestinationPath() - Constructor for class org.activemq.filter.DestinationPath
 
DestinationSecurityConfig - Class in org.activemq.security.jassjacc
 
DestinationSecurityConfig() - Constructor for class org.activemq.security.jassjacc.DestinationSecurityConfig
 
destoryMessageContainer(ActiveMQDestination) - Method in interface org.activemq.broker.BrokerAdmin
 
destoryMessageContainer(ActiveMQDestination) - Method in class org.activemq.broker.impl.DefaultBroker
 
destroy() - Method in class org.activemq.spring.BrokerFactoryBean
 
DESTROY_DESTINATION - Static variable in class org.activemq.message.BrokerAdminCommand
 
DESTROY_DESTINATION_ACTION - Static variable in class org.activemq.security.jassjacc.JMSBrokerPermission
 
destroyDestination(ActiveMQDestination) - Method in class org.activemq.ActiveMQConnection
Tells the broker to destroy a destination.
destroyMessageContainer(ActiveMQDestination) - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageManager
 
destroyMessageContainer(ActiveMQDestination) - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageManager
 
destroyMessageContainer(ActiveMQDestination) - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageManager
 
destroyMessageContainer(ActiveMQDestination) - Method in class org.activemq.service.impl.DurableQueueMessageContainerManager
 
destroyMessageContainer(ActiveMQDestination) - Method in class org.activemq.service.impl.DurableTopicMessageContainerManager
 
destroyMessageContainer(ActiveMQDestination) - Method in class org.activemq.service.impl.MessageContainerManagerSupport
 
destroyMessageContainer(ActiveMQDestination) - Method in class org.activemq.service.impl.ProxyMessageContainerManager
 
destroyMessageContainer(ActiveMQDestination) - Method in interface org.activemq.service.MessageContainerManager
Destroys a destination.
destroyObject(Object) - Method in class org.activemq.pool.SessionPool
 
destroySubcontext(Name) - Method in class org.activemq.jndi.ReadOnlyContext
 
destroySubcontext(String) - Method in class org.activemq.jndi.ReadOnlyContext
 
DISABLE_CLEAN_SHUTDOWN_PROPERTY - Static variable in class org.activemq.broker.impl.BrokerContainerImpl
 
disable_tracing() - Method in class org.activemq.selector.SelectorParser
 
disableTimeStampsByDefault - Variable in class org.activemq.ActiveMQConnectionFactory
 
DISCONNECT - Static variable in interface org.activemq.transport.stomp.Stomp.Commands
 
DISCONNECTED - Static variable in class org.activemq.transport.TransportStatusEvent
The channel has been disconnected, but maybe reconnected
DiscoveryAgent - Interface in org.activemq.transport
An agent used to discover other instances of a service.
DiscoveryAgentSupport - Class in org.activemq.transport
A useful base class for DiscoveryAgent implementations
DiscoveryAgentSupport() - Constructor for class org.activemq.transport.DiscoveryAgentSupport
 
DiscoveryEvent - Class in org.activemq.transport
Represents a discovery event containing the details of the service
DiscoveryEvent(DiscoveryAgent, String) - Constructor for class org.activemq.transport.DiscoveryEvent
 
DiscoveryEvent(DiscoveryAgent, String, Map) - Constructor for class org.activemq.transport.DiscoveryEvent
 
DiscoveryListener - Interface in org.activemq.transport
A listener of services being added or removed from a nework
DiscoveryNetworkConnector - Class in org.activemq.transport
A NetworkConnectorwhich uses discovery to find remote brokers to connect to
DiscoveryNetworkConnector(BrokerContainer) - Constructor for class org.activemq.transport.DiscoveryNetworkConnector
 
DiscoveryTransportChannel - Class in org.activemq.transport
A ReliableTransportChannel which uses a DiscoveryAgent to discover remote broker instances and dynamically connect to them.
DiscoveryTransportChannel(WireFormat, DiscoveryAgent) - Constructor for class org.activemq.transport.DiscoveryTransportChannel
 
DiscoveryTransportChannelFactorySupport - Class in org.activemq.transport
 
DiscoveryTransportChannelFactorySupport() - Constructor for class org.activemq.transport.DiscoveryTransportChannelFactorySupport
 
discoveryURI - Variable in class org.activemq.transport.peer.PeerTransportChannel
 
dispatch(ActiveMQMessage) - Method in class org.activemq.ActiveMQConnectionConsumer
Dispatch an ActiveMQMessage
dispatch(ActiveMQMessage) - Method in interface org.activemq.ActiveMQMessageDispatcher
Dispatch an ActiveMQMessage
dispatch(ActiveMQMessage) - Method in class org.activemq.ActiveMQSession
Dispatch an ActiveMQMessage
dispatch(ActiveMQMessage) - Method in interface org.activemq.broker.BrokerClient
Dispatch an ActiveMQMessage to the end client
dispatch(ActiveMQMessage) - Method in class org.activemq.broker.impl.BrokerClientImpl
Dispatch an ActiveMQMessage to the end client
dispatch - Variable in class org.activemq.service.impl.SubscriptionImpl
 
DISPATCHED_FROM_DLQ_INDEX - Static variable in class org.activemq.message.ActiveMQMessage
 
Dispatcher - Interface in org.activemq.service
A dispatcher of messages to some JMS connection.
dispatcher - Variable in class org.activemq.service.impl.MessageContainerManagerSupport
 
DispatcherImpl - Class in org.activemq.service.impl
A dispatcher of messages to some JMS connection.
DispatcherImpl() - Constructor for class org.activemq.service.impl.DispatcherImpl
 
dispatchMessages(Subscription, boolean) - Method in class org.activemq.service.impl.DispatchWorker
 
DispatchWorker - Class in org.activemq.service.impl
A Dispatcher that polls for updates for active Message Consumers
DispatchWorker() - Constructor for class org.activemq.service.impl.DispatchWorker
 
divide(Number, Number) - Method in class org.activemq.filter.ArithmeticExpression
 
doAcknowledge(boolean) - Method in class org.activemq.ActiveMQSession
 
doAddBefore(QueueListSupport.Header, QueueListSupport.Node, Object) - Method in class org.activemq.service.impl.QueueListSupport
 
doAddLast(Object, QueueListSupport.Header) - Method in class org.activemq.service.impl.QueueListSupport
 
doAddMessage(Connection, long, String, String, byte[]) - Method in class org.activemq.store.jdbc.adapter.BlobJDBCAdapter
 
doAddMessage(Connection, long, String, String, byte[], long) - Method in class org.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
doAddMessage(Connection, long, String, String, byte[], long) - Method in interface org.activemq.store.jdbc.JDBCAdapter
 
doAddMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.activemq.service.impl.DurableTopicMessageContainerManager
 
doAddXid(Connection, ActiveMQXid) - Method in class org.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
doAddXid(Connection, ActiveMQXid) - Method in interface org.activemq.store.jdbc.JDBCAdapter
 
doAsyncMethodInvoke(Method, Object[]) - Method in class org.activemq.util.AsyncProxy
 
doAsyncSend(Packet) - Method in class org.activemq.transport.activeio.ActiveIOTransportChannel
 
doAsyncSend(Packet) - Method in class org.activemq.transport.tcp.TcpTransportChannel
Actually performs the async send of a packet
doAsyncSend(Packet) - Method in class org.activemq.transport.TransportChannelSupport
send a Packet to the raw underlying transport This method is here to allow specific implementations to override this method
doClose() - Method in class org.activemq.ActiveMQSession
 
doClose() - Method in class org.activemq.transport.reliable.ReliableTransportChannel
 
doClose(Exception) - Method in class org.activemq.transport.tcp.TcpTransportChannel
 
doClose(Exception) - Method in class org.activemq.transport.vm.VmTransportChannel
 
doConsumePacket(Packet) - Method in class org.activemq.transport.stomp.StompTransportChannel
 
doConsumePacket(Packet) - Method in class org.activemq.transport.TransportChannelSupport
consume a packet from the channel
doConsumePacket(Packet, PacketListener) - Method in class org.activemq.transport.TransportChannelSupport
 
doCreateTables(Connection) - Method in class org.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
doCreateTables(Connection) - Method in interface org.activemq.store.jdbc.JDBCAdapter
 
doDeleteExpiredMessage(Connection, MessageIdentity) - Method in class org.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
doDeleteExpiredMessage(Connection, MessageIdentity) - Method in interface org.activemq.store.jdbc.JDBCAdapter
 
doDeleteOldMessages(Connection) - Method in class org.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
doDeleteOldMessages(Connection) - Method in interface org.activemq.store.jdbc.JDBCAdapter
 
doDeleteSubscription(Connection, String, String) - Method in class org.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
doDeleteSubscription(Connection, String, String) - Method in interface org.activemq.store.jdbc.JDBCAdapter
 
doDeRegistration(String) - Method in class org.activemq.broker.impl.BrokerContainerImpl
 
doDiscovery - Variable in class org.activemq.transport.peer.PeerTransportChannel
 
doDispatch(DurableMessagePointer) - Method in class org.activemq.service.boundedvm.DurableQueueSubscription
Dispatch a message to the Consumer
doDispatch(ActiveMQMessage) - Method in class org.activemq.service.boundedvm.TransientQueueSubscription
Dispatch a message to the Consumer
doDropTables(Connection) - Method in class org.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
doDropTables(Connection) - Method in interface org.activemq.store.jdbc.JDBCAdapter
 
doesSupportMessageCompression() - Method in class org.activemq.io.AbstractWireFormat
Some wire formats will not be able to understand compressed messages
doesSupportMessageCompression() - Method in interface org.activemq.io.WireFormat
Some wire formats will not be able to understand compressed messages
doesSupportMessageCompression() - Method in class org.activemq.transport.stomp.StompWireFormat
Some wire formats will not be able to understand compressed messages
doesSupportMessageCompression() - Method in interface org.activemq.transport.TransportChannel
Some transports/wireformats will not be able to understand compressed messages
doesSupportMessageCompression() - Method in class org.activemq.transport.TransportChannelSupport
Some transports/wireformats will not be able to understand compressed messages
doesSupportMessageCompression() - Method in class org.activemq.transport.vm.VmTransportChannel
Some transports/wireformats will not be able to understand compressed messages
doesSupportMessageFragmentation() - Method in class org.activemq.io.AbstractWireFormat
some wire formats will implement their own fragementation
doesSupportMessageFragmentation() - Method in interface org.activemq.io.WireFormat
some wire formats will implement their own fragementation
doesSupportMessageFragmentation() - Method in class org.activemq.transport.stomp.StompWireFormat
some wire formats will implement their own fragementation
doesSupportMessageFragmentation() - Method in interface org.activemq.transport.TransportChannel
some transports/wire formats will implement their own fragementation
doesSupportMessageFragmentation() - Method in class org.activemq.transport.TransportChannelSupport
some transports/wire formats will implement their own fragementation
doesSupportMessageFragmentation() - Method in class org.activemq.transport.vm.VmTransportChannel
some transports/wire formats will implement their own fragementation
doesSupportWireFormatVersioning() - Method in interface org.activemq.transport.TransportChannel
Does the transport support wire format version info
doesSupportWireFormatVersioning() - Method in class org.activemq.transport.TransportChannelSupport
Does the transport support wire format version info
doesSupportWireFormatVersioning() - Method in class org.activemq.transport.vm.VmTransportChannel
Does the transport support wire format version info
doFragmentation(ByteArray) - Method in class org.activemq.io.util.ByteArrayFragmentation
 
doGetExpiredMessages(Connection, JDBCAdapter.ExpiredMessageResultHandler) - Method in class org.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
doGetExpiredMessages(Connection, JDBCAdapter.ExpiredMessageResultHandler) - Method in interface org.activemq.store.jdbc.JDBCAdapter
 
doGetMessage(Connection, long) - Method in class org.activemq.store.jdbc.adapter.BlobJDBCAdapter
 
doGetMessage(Connection, long) - Method in class org.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
doGetMessage(Connection, long) - Method in interface org.activemq.store.jdbc.JDBCAdapter
 
doGetMessageForUpdate(Connection, long, boolean, JDBCAdapter.ExpiredMessageResultHandler) - Method in class org.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
doGetMessageForUpdate(Connection, long, boolean, JDBCAdapter.ExpiredMessageResultHandler) - Method in interface org.activemq.store.jdbc.JDBCAdapter
 
doGetSubscriberEntry(Connection, String, String) - Method in class org.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
doGetSubscriberEntry(Connection, String, String) - Method in interface org.activemq.store.jdbc.JDBCAdapter
 
doHandleReceipt(Packet) - Method in class org.activemq.transport.TransportChannelSupport
 
doHandleWireFormat(Packet) - Method in class org.activemq.transport.TransportChannelSupport
 
doLoadPreparedTransactions(Connection, TransactionStore.RecoveryListener) - Method in class org.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
doLoadPreparedTransactions(Connection, TransactionStore.RecoveryListener) - Method in interface org.activemq.store.jdbc.JDBCAdapter
 
doMessageCompression - Variable in class org.activemq.ActiveMQConnectionFactory
 
doMessageFragmentation - Variable in class org.activemq.ActiveMQConnectionFactory
 
doMessageSend(BrokerClient, ActiveMQMessage) - Method in class org.activemq.broker.impl.DefaultBroker
 
Done() - Method in class org.activemq.selector.SimpleCharStream
 
doPoll() - Method in class org.activemq.service.impl.DispatchWorker
 
doReconnect() - Method in class org.activemq.ActiveMQConnection
 
doReconnect(TransportChannel, long) - Method in class org.activemq.transport.reliable.ReliableTransportChannel
 
doRecover(Connection, String, JDBCAdapter.MessageListResultHandler) - Method in class org.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
doRecover(Connection, String, JDBCAdapter.MessageListResultHandler) - Method in interface org.activemq.store.jdbc.JDBCAdapter
 
doRecoverSubscription(Connection, String, String, JDBCAdapter.MessageListResultHandler) - Method in class org.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
doRecoverSubscription(Connection, String, String, JDBCAdapter.MessageListResultHandler) - Method in interface org.activemq.store.jdbc.JDBCAdapter
 
doRegistration(String) - Method in class org.activemq.broker.impl.BrokerContainerImpl
 
doRemoveAllMessages(Connection, String) - Method in class org.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
doRemoveAllMessages(Connection, String) - Method in interface org.activemq.store.jdbc.JDBCAdapter
 
doRemoveMessage(Connection, long) - Method in class org.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
doRemoveMessage(Connection, long) - Method in interface org.activemq.store.jdbc.JDBCAdapter
 
doRemoveNode(QueueListSupport.Node) - Method in class org.activemq.service.impl.QueueListSupport
 
doRemoveXid(Connection, ActiveMQXid) - Method in class org.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
doRemoveXid(Connection, ActiveMQXid) - Method in interface org.activemq.store.jdbc.JDBCAdapter
 
doSetDeadLetterFlag(Connection, long) - Method in class org.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
doSetDeadLetterFlag(Connection, long) - Method in interface org.activemq.store.jdbc.JDBCAdapter
 
doSetLastAck(Connection, String, String, long) - Method in class org.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
doSetLastAck(Connection, String, String, long) - Method in interface org.activemq.store.jdbc.JDBCAdapter
 
doSetSubscriberEntry(Connection, String, String, SubscriberEntry) - Method in class org.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
doSetSubscriberEntry(Connection, String, String, SubscriberEntry) - Method in interface org.activemq.store.jdbc.JDBCAdapter
 
doStartTransaction() - Method in class org.activemq.ActiveMQSession
Send TransactionInfo to indicate transaction has started
doStartTransaction() - Method in class org.activemq.ActiveMQXASession
This is called before transacted work is done by the session.
DOUBLE - Static variable in class org.activemq.filter.ArithmeticExpression
 
dump(IndentPrinter) - Method in class org.activemq.management.JMSConnectionStatsImpl
 
dump(IndentPrinter) - Method in class org.activemq.management.JMSConsumerStatsImpl
 
dump(IndentPrinter) - Method in class org.activemq.management.JMSEndpointStatsImpl
 
dump(IndentPrinter) - Method in class org.activemq.management.JMSProducerStatsImpl
 
dump(IndentPrinter) - Method in class org.activemq.management.JMSSessionStatsImpl
 
dump(IndentPrinter) - Method in class org.activemq.management.JMSStatsImpl
 
dumpContents() - Method in class org.activemq.io.util.MemoryBoundedQueueManager
 
DuplicateDurableSubscriptionException - Exception in org.activemq
There is only meant to be a single durable subscription open for a given clientID and subscriber name; this exception is thrown if a user tries to subscribe twice for the same clientID and subscriber name.
DuplicateDurableSubscriptionException(ConsumerInfo) - Constructor for exception org.activemq.DuplicateDurableSubscriptionException
 
DURABLE_UNSUBSCRIBE - Static variable in interface org.activemq.message.Packet
Durable Unsubscribe message
DurableMessagePointer - Class in org.activemq.service.boundedvm
DurableMessagePointers are moved around in the DurableQueueBoundedMessageManager so that we remember the associated messageStore that the message has been persisted to.
DurableMessagePointer(MessageStore, ActiveMQDestination, ActiveMQMessage) - Constructor for class org.activemq.service.boundedvm.DurableMessagePointer
 
DurableQueueBoundedMessageContainer - Class in org.activemq.service.boundedvm
A MessageContainer for Durable queues
DurableQueueBoundedMessageContainer(MessageStore, Executor, MemoryBoundedQueueManager, ActiveMQDestination, RedeliveryPolicy, DeadLetterPolicy) - Constructor for class org.activemq.service.boundedvm.DurableQueueBoundedMessageContainer
Construct this beast
DurableQueueBoundedMessageManager - Class in org.activemq.service.boundedvm
A MessageContainerManager for Durable queues
DurableQueueBoundedMessageManager(PersistenceAdapter, MemoryBoundedQueueManager, RedeliveryPolicy, DeadLetterPolicy) - Constructor for class org.activemq.service.boundedvm.DurableQueueBoundedMessageManager
Constructor for DurableQueueBoundedMessageManager
DurableQueueBoundedMessageManager.DurableQueueThreadFactory - Class in org.activemq.service.boundedvm
 
DurableQueueBoundedMessageManager.DurableQueueThreadFactory() - Constructor for class org.activemq.service.boundedvm.DurableQueueBoundedMessageManager.DurableQueueThreadFactory
 
DurableQueueMessageContainer - Class in org.activemq.service.impl
A default implementation of a Durable Queue based MessageContainer which acts as an adapter between the MessageContainerManager requirements and those of the persistent MessageStore implementations.
DurableQueueMessageContainer(PersistenceAdapter, MessageStore, String) - Constructor for class org.activemq.service.impl.DurableQueueMessageContainer
 
DurableQueueMessageContainer(PersistenceAdapter, MessageStore, String, QueueList, QueueList) - Constructor for class org.activemq.service.impl.DurableQueueMessageContainer
 
DurableQueueMessageContainerManager - Class in org.activemq.service.impl
A default Broker used for Queue messages
DurableQueueMessageContainerManager(PersistenceAdapter, RedeliveryPolicy, DeadLetterPolicy) - Constructor for class org.activemq.service.impl.DurableQueueMessageContainerManager
 
DurableQueueMessageContainerManager(PersistenceAdapter, SubscriptionContainer, FilterFactory, Dispatcher) - Constructor for class org.activemq.service.impl.DurableQueueMessageContainerManager
 
DurableQueueSubscription - Class in org.activemq.service.boundedvm
A holder for Durable Queue consumer info and message routing
DurableQueueSubscription(BrokerClient, MemoryBoundedQueue, MemoryBoundedQueue, Filter, ConsumerInfo) - Constructor for class org.activemq.service.boundedvm.DurableQueueSubscription
Construct the DurableQueueSubscription
durableSubAcksTableName - Variable in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
DurableSubscription - Class in org.activemq.service.boundedvm
A holder for Durable consumer info and message routing
DurableSubscription(Filter, ConsumerInfo, BrokerClient) - Constructor for class org.activemq.service.boundedvm.DurableSubscription
Construct the DurableSubscription
DurableTopicMessageContainer - Class in org.activemq.service.impl
A default implementation of a Durable Topic based MessageContainer which acts as an adapter between the MessageContainerManager requirements and those of the persistent TopicMessageStore implementations.
DurableTopicMessageContainer(DurableTopicMessageContainerManager, TopicMessageStore, String) - Constructor for class org.activemq.service.impl.DurableTopicMessageContainer
 
DurableTopicMessageContainerManager - Class in org.activemq.service.impl
A default Broker used for Topic messages for durable consumers
DurableTopicMessageContainerManager(PersistenceAdapter, RedeliveryPolicy, DeadLetterPolicy) - Constructor for class org.activemq.service.impl.DurableTopicMessageContainerManager
 
DurableTopicMessageContainerManager(PersistenceAdapter, SubscriptionContainer, FilterFactory, Dispatcher) - Constructor for class org.activemq.service.impl.DurableTopicMessageContainerManager
 
DurableTopicSubscription - Class in org.activemq.service.impl
Represents a durable topic subscription where the consumer has a unique clientID used to persist the messages across both Broker restarts and JMS client restarts
DurableTopicSubscription(Dispatcher, BrokerClient, ConsumerInfo, Filter, RedeliveryPolicy, DeadLetterPolicy) - Constructor for class org.activemq.service.impl.DurableTopicSubscription
 
DurableTopicSubscriptionContainerImpl - Class in org.activemq.service.impl
An implemenation of SubscriptionContainerImpl for durable topic subscriptions
DurableTopicSubscriptionContainerImpl(RedeliveryPolicy, DeadLetterPolicy) - Constructor for class org.activemq.service.impl.DurableTopicSubscriptionContainerImpl
 
DurableTopicSubscriptionContainerImpl(Map, RedeliveryPolicy, DeadLetterPolicy) - Constructor for class org.activemq.service.impl.DurableTopicSubscriptionContainerImpl
 
durableUnsubscribe(BrokerClient, DurableUnsubscribe) - Method in interface org.activemq.broker.BrokerConnector
Command to delete a durable topic subscription
durableUnsubscribe(BrokerClient, DurableUnsubscribe) - Method in interface org.activemq.broker.BrokerContainer
Command to delete a durable topic subscription
durableUnsubscribe(BrokerClient, DurableUnsubscribe) - Method in class org.activemq.broker.impl.BrokerConnectorImpl
Command to delete a durable topic subscription
durableUnsubscribe(BrokerClient, DurableUnsubscribe) - Method in class org.activemq.broker.impl.BrokerContainerImpl
Command to delete a durable topic subscription
DurableUnsubscribe - Class in org.activemq.message
Command to remove a Durable Subscription
DurableUnsubscribe() - Constructor for class org.activemq.message.DurableUnsubscribe
 
durableUnsubscribeReader - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
DurableUnsubscribeReader - Class in org.activemq.io.impl
Reads a DurableUnsubscribe object from a Stream
DurableUnsubscribeReader() - Constructor for class org.activemq.io.impl.DurableUnsubscribeReader
 
durableUnsubscribeWriter - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
DurableUnsubscribeWriter - Class in org.activemq.io.impl
Writes a DurableUnsubscribe object to a Stream
DurableUnsubscribeWriter() - Constructor for class org.activemq.io.impl.DurableUnsubscribeWriter
 

E

empty() - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageContainer
 
empty() - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
 
empty() - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
 
empty() - Method in class org.activemq.service.impl.DurableQueueMessageContainer
 
empty() - Method in class org.activemq.service.impl.DurableTopicMessageContainer
 
empty() - Method in interface org.activemq.service.MessageContainerAdmin
Deletes all the messages that a container holds.
EMPTY_ARRAY - Static variable in interface org.activemq.service.QueueList
 
EMPTY_DESTINATION - Static variable in class org.activemq.message.BrokerAdminCommand
 
enable_tracing() - Method in class org.activemq.selector.SelectorParser
 
encodeBinary(byte[], int, int) - Method in class org.activemq.transport.jabber.JabberWireFormat
 
encodeString(String) - Static method in class org.activemq.filter.ConstantExpression
Encodes the value of string so that it looks like it would look like when it was provided in a selector.
END - Static variable in interface org.activemq.message.TransactionType
End a transaction
end(Xid, int) - Method in class org.activemq.TransactionContext
 
endColumn - Variable in class org.activemq.selector.Token
beginLine and beginColumn describe the position of the first character of this token; endLine and endColumn describe the position of the last character of this token.
endLine - Variable in class org.activemq.selector.Token
beginLine and beginColumn describe the position of the first character of this token; endLine and endColumn describe the position of the last character of this token.
enqueue(MemoryManageable) - Method in class org.activemq.io.util.MemoryBoundedQueue
Enqueue a MemoryManageable to this queue
enqueue(ActiveMQMessage) - Method in class org.activemq.io.util.SpooledBoundedActiveMQMessageQueue
Place a ActiveMQMessage at the head of the Queue
enqueue(ActiveMQMessage) - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageContainer
enqueue a message for dispatching
enqueue(ActiveMQMessage) - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
enqueue a message for dispatching
enqueueAllFirstNoBlock(List) - Method in class org.activemq.io.util.MemoryBoundedPrioritizedQueue
Enqueue an array of packets to the head of the queue with total disregard for memory constraints
enqueueAllFirstNoBlock(List) - Method in class org.activemq.io.util.MemoryBoundedQueue
Enqueue an array of packets to the head of the queue with total disregard for memory constraints
enqueueFirst(MemoryManageable) - Method in class org.activemq.io.util.MemoryBoundedQueue
Enqueue a MemoryManageable to the head of the queue
enqueueFirstNoBlock(MemoryManageable) - Method in class org.activemq.io.util.MemoryBoundedPrioritizedQueue
Enqueue a packet to the head of the queue with total disregard for memory constraints
enqueueFirstNoBlock(MemoryManageable) - Method in class org.activemq.io.util.MemoryBoundedQueue
Enqueue a packet to the head of the queue with total disregard for memory constraints
enqueueNoBlock(MemoryManageable) - Method in class org.activemq.io.util.MemoryBoundedPrioritizedQueue
Enqueue a MemoryManageable without checking memory usage limits
enqueueNoBlock(MemoryManageable) - Method in class org.activemq.io.util.MemoryBoundedQueue
Enqueue a MemoryManageable without checking memory usage limits
enqueueNoBlock(ActiveMQMessage) - Method in class org.activemq.io.util.SpooledBoundedActiveMQMessageQueue
Enqueue a ActiveMQMessage without checking usage limits
enqueuePacket(Packet) - Method in class org.activemq.transport.stomp.StompWireFormat
 
ensureMulticastChannelIsAvailable(URI, TransportChannel, BrokerConnector, boolean) - Method in class org.activemq.ActiveMQConnectionFactory
 
ensureServerIsAvailable(URI, TransportChannel, BrokerConnector, boolean) - Method in class org.activemq.ActiveMQConnectionFactory
 
entry(int) - Method in class org.activemq.service.impl.DefaultQueueList
 
environment - Variable in class org.activemq.jndi.ReadOnlyContext
 
EOF - Static variable in interface org.activemq.selector.SelectorParserConstants
 
eol - Variable in exception org.activemq.selector.ParseException
The end of line string for this machine.
equal(Object, Object) - Method in class org.activemq.service.impl.DurableTopicMessageContainerManager
Returns true if the two objects are null or are equal
equal(Object, Object) - Static method in class org.activemq.service.impl.SubscriptionImpl
 
equalityExpression() - Method in class org.activemq.selector.SelectorParser
 
equals(Object) - Method in class org.activemq.ActiveMQQueueSession
 
equals(Object) - Method in class org.activemq.ActiveMQTopicSession
 
equals(Object) - Method in class org.activemq.advisories.TempDestinationAdvisoryEvent
 
equals(Object) - Method in class org.activemq.filter.BinaryExpression
TODO: more efficient hashCode()
equals(Object) - Method in class org.activemq.filter.ConstantExpression
TODO: more efficient hashCode()
equals(Object) - Method in class org.activemq.filter.MultiExpressionEvaluator.CacheExpression
 
equals(Object) - Method in class org.activemq.filter.PropertyExpression
 
equals(Object) - Method in class org.activemq.filter.UnaryExpression
TODO: more efficient hashCode()
equals(Object) - Method in class org.activemq.message.AbstractPacket
Tests equality with another instance
equals(Object, Object) - Method in class org.activemq.message.AbstractPacket
A helper method used when implementing equals() which returns true if the objects are identical or equal handling nulls properly
equals(Object) - Method in class org.activemq.message.ActiveMQDestination
if the object passed in is equivalent, return true
equals(Object) - Method in class org.activemq.message.ActiveMQMessage
Returns true if this instance is equivalent to obj
equals(Object) - Method in class org.activemq.message.ActiveMQXid
 
equals(Xid, Xid) - Static method in class org.activemq.message.ActiveMQXid
Test for equivlance between two Xid
equals(byte[], byte[]) - Static method in class org.activemq.message.ActiveMQXid
 
equals(Object) - Method in class org.activemq.message.BrokerAdminCommand
Test for equality
equals(Object) - Method in class org.activemq.message.CleanupConnectionInfo
Test for equality
equals(Object) - Method in class org.activemq.message.ConnectionInfo
Test for equality
equals(Object) - Method in class org.activemq.message.ConsumerInfo
Test for equality
equals(Object) - Method in class org.activemq.message.ProducerInfo
Test for equality
equals(Object) - Method in class org.activemq.message.SessionInfo
Test for equality
equals(Object) - Method in class org.activemq.message.TransactionInfo
Test for equality
equals(Object) - Method in class org.activemq.message.XATransactionInfo
Test for equality
equals(Object) - Method in class org.activemq.pool.ConnectionKey
 
equals(ConnectionKey) - Method in class org.activemq.pool.ConnectionKey
 
equals(Object) - Method in class org.activemq.pool.SessionKey
 
equals(SessionKey) - Method in class org.activemq.pool.SessionKey
 
equals(Object) - Method in class org.activemq.security.jassjacc.AbstractJMSPermission
 
equals(Object) - Method in class org.activemq.service.impl.MessageEntry
Tests equivalence with an other object
equals(Object) - Method in class org.activemq.service.MessageIdentity
 
equals(MessageIdentity) - Method in class org.activemq.service.MessageIdentity
 
ERROR - Static variable in interface org.activemq.transport.stomp.Stomp.Responses
 
ESCAPE - Static variable in interface org.activemq.selector.SelectorParserConstants
 
establishConnection(long) - Method in class org.activemq.transport.composite.CompositeTransportChannel
 
establishConnectionTimeout - Variable in class org.activemq.transport.composite.CompositeTransportChannel
 
evaluate(Message) - Method in class org.activemq.filter.ArithmeticExpression
 
evaluate(Object, Object) - Method in class org.activemq.filter.ArithmeticExpression
 
evaluate(Message) - Method in class org.activemq.filter.ComparisonExpression
 
evaluate(Message) - Method in class org.activemq.filter.ConstantExpression
 
evaluate(Message) - Method in interface org.activemq.filter.Expression
 
evaluate(Message) - Method in class org.activemq.filter.JAXPXPathEvaluator
 
evaluate(Message) - Method in class org.activemq.filter.LogicExpression
 
evaluate(Message) - Method in class org.activemq.filter.MultiExpressionEvaluator.CacheExpression
 
evaluate(Message) - Method in class org.activemq.filter.MultiExpressionEvaluator
Evaluates the message against all the Expressions added to this object.
evaluate(Message) - Method in class org.activemq.filter.PropertyExpression
 
evaluate(Message) - Method in class org.activemq.filter.XalanXPathEvaluator
 
evaluate(Message) - Method in class org.activemq.filter.XMLBeansXPathEvaluator
 
evaluate(Message) - Method in class org.activemq.filter.XPathExpression
 
evaluate(Message) - Method in interface org.activemq.filter.XPathExpression.XPathEvaluator
 
evaluate(Message) - Method in class org.activemq.filter.XQueryExpression
 
ExceptionTemplate - Class in org.activemq.util
A helper class for ensuring that a number of tasks occur, whether they throw exceptions or not and saving the first exception so that we can throw it properly.
ExceptionTemplate() - Constructor for class org.activemq.util.ExceptionTemplate
 
execute() - Method in interface org.activemq.service.TransactionTask
 
execute() - Method in interface org.activemq.util.Callback
Executes some piece of code within a transaction performing a commit if there is no exception thrown else a rollback is performed
ExecutorHelper - Class in org.activemq.util
A helper class for working with Executor objects
ExecutorHelper() - Constructor for class org.activemq.util.ExecutorHelper
 
expectedTokenSequences - Variable in exception org.activemq.selector.ParseException
Each entry in this array is an array of integers.
EXPIRATION_INDEX - Static variable in class org.activemq.message.ActiveMQMessage
 
EXPIRATION_TIME - Static variable in interface org.activemq.transport.stomp.Stomp.Headers.Message
 
EXPIRATION_TIME - Static variable in interface org.activemq.transport.stomp.Stomp.Headers.Send
 
EXPIRED_INDEX - Static variable in class org.activemq.message.MessageAck
 
expiredMessageCount - Variable in class org.activemq.management.JMSEndpointStatsImpl
 
EXPONENT - Static variable in interface org.activemq.selector.SelectorParserConstants
 
Expression - Interface in org.activemq.filter
Represents an expression
ExpressionFilter - Class in org.activemq.filter
Represents a filter using an expression
ExpressionFilter(Expression) - Constructor for class org.activemq.filter.ExpressionFilter
 
EXTERNAL_MESSAGE_ID_INDEX - Static variable in class org.activemq.message.ActiveMQMessage
 
EXTERNAL_MESSAGE_ID_INDEX - Static variable in class org.activemq.message.MessageAck
 
extractURI(List) - Method in class org.activemq.transport.composite.CompositeTransportChannel
 
extractURI(List) - Method in class org.activemq.transport.reliable.ReliableTransportChannel
 

F

FactoryFinder - Class in org.activemq.util
A helper class to discover protocols dynamically to ensure that the system is extensible and has minimum runtime dependencies
FactoryFinder(String) - Constructor for class org.activemq.util.FactoryFinder
 
FAILED - Static variable in class org.activemq.transport.TransportStatusEvent
The channel has failed
failureSleepTime - Variable in class org.activemq.transport.composite.CompositeTransportChannel
 
FALSE - Static variable in class org.activemq.filter.ConstantExpression
 
FALSE - Static variable in interface org.activemq.selector.SelectorParserConstants
 
FastInputStream - Class in org.activemq.util
This provides InputStream that delegates to com.sleepycat.util.FastInputStream if it is available and if it is not it delegates to java.io.ByteArrayInputStream.
FastInputStream(byte[]) - Constructor for class org.activemq.util.FastInputStream
 
FastOutputStream - Class in org.activemq.util
This provides OutputStream that delegates to com.sleepycat.util.FastOutputStream if it is available and if it is not it delegates to java.io.ByteArrayOutputStream.
FastOutputStream() - Constructor for class org.activemq.util.FastOutputStream
 
Filter - Interface in org.activemq.filter
Represents a subscription filter
filter - Variable in class org.activemq.service.boundedvm.DurableSubscription
 
filter - Variable in class org.activemq.service.boundedvm.TransientSubscription
 
FilterFactory - Interface in org.activemq.filter
A factory of subscription Filter objects
filterFactory - Variable in class org.activemq.service.impl.DurableQueueMessageContainerManager
 
filterFactory - Variable in class org.activemq.service.impl.DurableTopicMessageContainerManager
 
FilterFactoryImpl - Class in org.activemq.filter
A default implementation
FilterFactoryImpl() - Constructor for class org.activemq.filter.FilterFactoryImpl
 
finalize() - Method in class org.activemq.io.util.MemoryBoundedObjectManager
 
findClass(String) - Method in class org.activemq.util.FactoryFinder
Loads the class for the given key
findWildcardMatches(ActiveMQDestination) - Method in class org.activemq.filter.DestinationMap
 
FINISHED_STATE - Static variable in class org.activemq.service.impl.AbstractTransaction
 
fireAddService(DiscoveryEvent) - Method in class org.activemq.transport.DiscoveryAgentSupport
 
fireConsumerInfo(BrokerClient, ConsumerInfo) - Method in class org.activemq.broker.impl.DefaultBroker
 
fireException(JMSException) - Method in class org.activemq.transport.reliable.ReliableTransportChannel
Fire a JMSException to the exception listener
fireRemoveService(DiscoveryEvent) - Method in class org.activemq.transport.DiscoveryAgentSupport
 
fireStatusEvent(URI, int) - Method in class org.activemq.transport.TransportChannelSupport
Fire status event to any status event listeners
fireStatusEvent(TransportStatusEvent) - Method in class org.activemq.transport.TransportChannelSupport
Fire status event to any status event listeners
FLOATING_POINT_LITERAL - Static variable in interface org.activemq.selector.SelectorParserConstants
 
flush() - Method in class org.activemq.streams.JMSOutputStream
flush the data to the output stream This doesn't call flush on the underlying outputstream, because Tcp is particularly efficent at doing this itself ....
flush() - Method in class org.activemq.transport.tcp.TcpBufferedOutputStream
flush the data to the output stream This doesn't call flush on the underlying outputstream, because Tcp is particularly efficent at doing this itself ....
flush() - Method in class org.activemq.util.IndentPrinter
 
flushMessages() - Method in class org.activemq.spring.TestingConsumer
 
FlushPacket - Class in org.activemq.transport.stomp
Dummy Marker packet to let the transport layer know that it should flush the wireformat.
forceDisconnect() - Method in class org.activemq.transport.activeio.ActiveIOTransportChannel
 
forceDisconnect() - Method in class org.activemq.transport.composite.CompositeTransportChannel
Forces disconnect by delegating to the child channel
forceDisconnect() - Method in class org.activemq.transport.tcp.TcpTransportChannel
 
forceDisconnect() - Method in interface org.activemq.transport.TransportChannel
Forces an immediate transport-level disconnect which will be asynchronously reported as an exception to the exceptionListener.
forceDisconnect() - Method in class org.activemq.transport.udp.UdpTransportChannel
 
forceDisconnect() - Method in class org.activemq.transport.vm.VmTransportChannel
 
FORGET - Static variable in interface org.activemq.message.TransactionType
Forget a transaction
forget(Xid) - Method in class org.activemq.TransactionContext
 
fragment(ByteArray) - Method in class org.activemq.io.util.ByteArrayFragmentation
Fragment a ByteArray into a number of parts
freeze() - Method in class org.activemq.jndi.ReadOnlyContext
 
fromBytes(byte[], int, int) - Method in class org.activemq.io.AbstractWireFormat
Reads the packet from the given byte[]
fromBytes(byte[]) - Method in class org.activemq.io.AbstractWireFormat
Reads the packet from the given byte[]
fromBytes(byte[], int, int) - Method in interface org.activemq.io.WireFormat
Reads the packet from the given byte[]
fromBytes(byte[]) - Method in interface org.activemq.io.WireFormat
Reads the packet from the given byte[]
fromBytes(byte[]) - Static method in class org.activemq.message.ActiveMQXid
Deserializes the data into an Xid
fromBytes(byte[]) - Method in class org.activemq.service.impl.QueueListSupport.Header
 
fromBytes(byte[]) - Method in class org.activemq.service.impl.QueueListSupport.Node
 
fromBytes(byte[], int, int) - Method in class org.activemq.transport.stomp.StompWireFormat
Reads the packet from the given byte[]
fromBytes(byte[]) - Method in class org.activemq.transport.stomp.StompWireFormat
Reads the packet from the given byte[]
fromString(String) - Method in class org.activemq.io.TextWireFormat
Converts the String into a Packet

G

generateCapacityMonitorEvent() - Method in class org.activemq.capacity.BasicCapacityMonitor
 
generateCapacityMonitorEvent() - Method in interface org.activemq.capacity.CapacityMonitor
 
generateCapacityMonitorEvent() - Method in class org.activemq.capacity.DelegateCapacityMonitor
 
generateConsumerKey(String, String) - Static method in class org.activemq.message.ConsumerInfo
Generate a primary key for a consumer from the clientId and consumerName
generateId() - Method in class org.activemq.util.IdGenerator
Generate a unqiue id
generateParseException() - Method in class org.activemq.selector.SelectorParser
 
generateSessionId() - Method in class org.activemq.ActiveMQConnection
 
get(ActiveMQDestination) - Method in class org.activemq.filter.DestinationMap
Looks up the value(s) matching the given Destination key.
get(int) - Method in class org.activemq.io.util.ByteArray
return the byte at the position
get(String) - Method in class org.activemq.io.util.MemoryBoundedMessageCache
Gets a message that was previously put into this object.
get(int) - Method in class org.activemq.io.util.MemoryBoundedPrioritizedQueue
retrieve a MemoryManageable at an indexed position in the queue
get(int) - Method in class org.activemq.io.util.MemoryBoundedQueue
retrieve a MemoryManageable at an indexed position in the queue
get(int) - Method in class org.activemq.service.impl.DefaultQueueList
 
get(Object) - Method in class org.activemq.service.impl.DefaultQueueList
get the object from the queue
get(int) - Method in class org.activemq.service.impl.QueueListSupport
 
get(int) - Method in interface org.activemq.service.QueueList
Returns the element at the specified position in this list.
get(String) - Method in interface org.activemq.store.cache.MessageCache
Gets a message that was previously put into this object.
get(String) - Method in class org.activemq.store.cache.SimpleMessageCache
Gets a message that was previously put into this object.
get(int) - Method in class org.activemq.util.BitArray
 
GET_RM_ID - Static variable in interface org.activemq.message.TransactionType
Gets the unique id of the resource manager.
GET_TX_TIMEOUT - Static variable in interface org.activemq.message.TransactionType
Get a the transaction timeout for the RM
getAccessControlContext(BrokerClient) - Method in class org.activemq.security.jassjacc.JassJaccSecurityAdapter
 
getAckListeners() - Method in class org.activemq.transport.stomp.StompWireFormat
 
getAckMode() - Method in class org.activemq.pool.SessionKey
 
getAcknowledgeMode() - Method in class org.activemq.ActiveMQQueueSession
 
getAcknowledgeMode() - Method in class org.activemq.ActiveMQSession
Returns the acknowledgement mode of the session.
getAcknowledgeMode() - Method in class org.activemq.ActiveMQTopicSession
 
getAcknowledgeMode() - Method in class org.activemq.pool.PooledSession
 
getAcks() - Method in class org.activemq.store.journal.JournalTransactionStore.Tx
 
getAcks() - Method in class org.activemq.store.vm.VMTransactionStore.Tx
 
getActions() - Method in class org.activemq.security.jassjacc.AbstractJMSPermission
 
getActiveClient() - Method in class org.activemq.service.impl.SubscriptionImpl
 
getAdapterClass() - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
getAddMessageStatment() - Method in class org.activemq.store.jdbc.adapter.CachingStatementProvider
 
getAddMessageStatment() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getAddMessageStatment() - Method in interface org.activemq.store.jdbc.StatementProvider
 
getAddXidStatment() - Method in class org.activemq.store.jdbc.adapter.CachingStatementProvider
 
getAddXidStatment() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getAddXidStatment() - Method in interface org.activemq.store.jdbc.StatementProvider
 
getAnyChildNode() - Method in class org.activemq.filter.DestinationMapNode
Returns the node which represents all children (i.e.
getAssemblies() - Method in class org.activemq.ActiveMQConnection
 
getAsyncChannel() - Method in class org.activemq.transport.activeio.ActiveIOTransportChannel
 
getAveragePerSecond() - Method in class org.activemq.management.TimeStatisticImpl
 
getAveragePerSecondExcludingMinMax() - Method in class org.activemq.management.TimeStatisticImpl
 
getAverageTime() - Method in class org.activemq.management.TimeStatisticImpl
 
getAverageTimeExcludingMinMax() - Method in class org.activemq.management.TimeStatisticImpl
 
getBacklog() - Method in class org.activemq.transport.tcp.TcpTransportServerChannel
 
getBackOffIncreaseRate() - Method in class org.activemq.service.RedeliveryPolicy
 
getBeginColumn() - Method in class org.activemq.selector.SimpleCharStream
 
getBeginLine() - Method in class org.activemq.selector.SimpleCharStream
 
getBinaryData(ResultSet, int) - Method in class org.activemq.store.jdbc.adapter.BytesJDBCAdapter
 
getBinaryData(ResultSet, int) - Method in class org.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
getBinaryData(ResultSet, int) - Method in class org.activemq.store.jdbc.adapter.OracleJDBCAdapter
 
getBinaryData(ResultSet, int) - Method in class org.activemq.store.jdbc.adapter.StreamJDBCAdapter
 
getBinaryDataType() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getBit(long) - Method in class org.activemq.util.BitArrayBin
Get the boolean value at the index
getBitArray() - Method in class org.activemq.message.AbstractPacket
 
getBits() - Method in class org.activemq.util.BitArray
 
getBodyAsBytes() - Method in class org.activemq.message.ActiveMQBytesMessage
 
getBodyAsBytes() - Method in class org.activemq.message.ActiveMQMessage
 
getBodyAsBytes(ByteArrayCompression) - Method in class org.activemq.message.ActiveMQMessage
return the data after applying compression
getBodyAsBytes() - Method in class org.activemq.message.ActiveMQStreamMessage
 
getBodyLength() - Method in class org.activemq.message.ActiveMQBytesMessage
Gets the number of bytes of the message body when the message is in read-only mode.
getBoolean(Properties, String) - Method in class org.activemq.ActiveMQConnectionFactory
Helper method to return the property value as a boolean flag
getBoolean(Properties, String, boolean) - Method in class org.activemq.ActiveMQConnectionFactory
Helper method to return the property value as a boolean flag
getBoolean(String) - Method in class org.activemq.message.ActiveMQMapMessage
Returns the boolean value with the specified name.
getBooleanProperty(String) - Method in class org.activemq.message.ActiveMQMessage
Returns the value of the boolean property with the specified name.
getBranchQualifier() - Method in class org.activemq.message.ActiveMQXid
 
getBroker() - Method in interface org.activemq.broker.BrokerContainer
 
getBroker() - Method in class org.activemq.broker.impl.BrokerContainerImpl
 
getBroker() - Method in class org.activemq.service.DeadLetterPolicy
 
getBrokerAdmin() - Method in interface org.activemq.broker.Broker
Get's the admin interface of the broker.
getBrokerAdmin() - Method in class org.activemq.broker.impl.DefaultBroker
 
getBrokerCapacity() - Method in interface org.activemq.broker.BrokerConnector
Get a hint about the broker capacity for more messages
getBrokerCapacity() - Method in class org.activemq.broker.impl.BrokerConnectorImpl
Get a hint about the broker capacity for more messages
getBrokerClient() - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
 
getBrokerClusterName() - Method in interface org.activemq.broker.Broker
 
getBrokerClusterName() - Method in class org.activemq.broker.impl.DefaultBroker
 
getBrokerConnector() - Method in interface org.activemq.broker.BrokerClient
 
getBrokerConnector() - Method in class org.activemq.broker.impl.BrokerClientImpl
 
getBrokerConnectorURI() - Method in class org.activemq.transport.peer.PeerTransportChannel
 
getBrokerContainer() - Method in class org.activemq.ActiveMQConnectionFactory
 
getBrokerContainer() - Method in interface org.activemq.broker.BrokerConnector
 
getBrokerContainer() - Method in class org.activemq.broker.impl.BrokerConnectorImpl
 
getBrokerContainer() - Method in class org.activemq.broker.impl.DefaultBroker
 
getBrokerContainer() - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
getBrokerContainer() - Method in class org.activemq.transport.NetworkChannel
 
getBrokerContainer() - Method in class org.activemq.transport.NetworkConnector
 
getBrokerContainerByName(String, String, BrokerContainerFactory) - Method in class org.activemq.broker.BrokerContext
 
getBrokerContainerFactory() - Method in class org.activemq.ActiveMQConnectionFactory
 
getBrokerContext() - Method in class org.activemq.ActiveMQConnectionFactory
Returns the context used to store broker containers and connectors which defaults to using the singleton
getBrokerInfo() - Method in interface org.activemq.broker.Broker
 
getBrokerInfo() - Method in interface org.activemq.broker.BrokerConnector
 
getBrokerInfo() - Method in class org.activemq.broker.impl.BrokerConnectorImpl
 
getBrokerInfo() - Method in class org.activemq.broker.impl.DefaultBroker
 
getBrokerMessageCapacity() - Method in class org.activemq.message.Receipt
 
getBrokerName() - Method in class org.activemq.ActiveMQConnectionFactory
The name of the broker to use if creating an embedded broker
getBrokerName(String) - Method in class org.activemq.ActiveMQConnectionFactory
The name of the broker to use if creating an embedded broker
getBrokerName() - Method in interface org.activemq.broker.Broker
 
getBrokerName() - Method in class org.activemq.broker.impl.DefaultBroker
 
getBrokerName() - Method in class org.activemq.message.BrokerInfo
 
getBrokerName() - Method in class org.activemq.message.Receipt
 
getBrokerName() - Method in class org.activemq.security.jassjacc.BrokerSecurityConfig
 
getBrokerName() - Method in class org.activemq.security.jassjacc.DestinationSecurityConfig
 
getBrokerName(BrokerClient) - Static method in class org.activemq.security.jassjacc.JassJaccSecurityAdapter
 
getBrokerName() - Method in class org.activemq.spring.ActiveMQBeanDefinitionReader
 
getBrokerName() - Method in class org.activemq.transport.peer.PeerTransportChannel
 
getBrokerName() - Method in class org.activemq.transport.remote.RemoteTransportChannel
 
getBrokerSecurityConfig() - Method in class org.activemq.security.jassjacc.PropertiesConfigLoader
 
getBrokersVisited() - Method in class org.activemq.message.AbstractPacket
 
getBrokersVisitedAsString() - Method in class org.activemq.message.AbstractPacket
 
getBrokersVisitedAsString() - Method in interface org.activemq.message.Packet
 
getBrokerURL() - Method in class org.activemq.ActiveMQConnectionFactory
 
getBrokerXmlConfig() - Method in class org.activemq.ActiveMQConnectionFactory
 
getBuf() - Method in class org.activemq.io.util.ByteArray
 
getByte(String) - Method in class org.activemq.message.ActiveMQMapMessage
Returns the byte value with the specified name.
getByteProperty(String) - Method in class org.activemq.message.ActiveMQMessage
Returns the value of the byte property with the specified name.
getBytes(String) - Method in class org.activemq.message.ActiveMQMapMessage
Returns the byte array value with the specified name.
getCacheSize() - Method in class org.activemq.store.cache.SimpleCachePersistenceAdapter
 
getCapacity() - Method in interface org.activemq.broker.BrokerClient
Get the Capacity for in-progress messages at the peer (probably a JMSConnection) Legimate values between 0-100.
getCapacity() - Method in class org.activemq.broker.impl.BrokerClientImpl
Get the Capacity for in-progress messages at the peer (probably a JMSConnection) Legimate values between 0-100.
getCapacity() - Method in class org.activemq.capacity.CapacityMonitorEvent
 
getCapacity() - Method in class org.activemq.message.CapacityInfo
 
getChannel() - Method in interface org.activemq.broker.BrokerClient
 
getChannel() - Method in class org.activemq.broker.impl.BrokerClientImpl
 
getChannel() - Method in class org.activemq.transport.composite.CompositeTransportChannel
Access to the current channel if one is active
getChannelName() - Method in class org.activemq.transport.multicast.MulticastDiscoveryAgent
 
getChannelStatus() - Method in class org.activemq.transport.TransportStatusEvent
 
getChar(String) - Method in class org.activemq.message.ActiveMQMapMessage
Returns the Unicode character value with the specified name.
getCheckInterval() - Method in class org.activemq.transport.reliable.KeepAliveDaemon
 
getCheckpointInterval() - Method in class org.activemq.store.journal.JournalPersistenceAdapter
 
getChild(String) - Method in class org.activemq.filter.DestinationMapNode
Returns the child node for the given named path or null if it does not exist
getChildDestinations() - Method in class org.activemq.message.ActiveMQDestination
Returns a list of child destinations if this destination represents a composite destination.
getChildOrCreate(String) - Method in class org.activemq.filter.DestinationMapNode
Returns the child node for the given named path, lazily creating one if it does not yet exist
getClassName(Class) - Static method in class org.activemq.util.ClassLoading
 
getCleanupPeriod() - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
getCleanupRepeatInterval() - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
getClientID() - Method in class org.activemq.ActiveMQConnection
Gets the client identifier for this connection.
getClientID() - Method in class org.activemq.ActiveMQConnectionFactory
 
getClientID() - Method in interface org.activemq.broker.BrokerClient
 
getClientID() - Method in class org.activemq.broker.impl.BrokerClientImpl
 
getClientID() - Method in exception org.activemq.DuplicateDurableSubscriptionException
 
getClientId(ActiveMQDestination) - Static method in class org.activemq.message.ActiveMQDestination
From a temporary destination find the clientId of the Connection that created it
getClientId() - Method in class org.activemq.message.CleanupConnectionInfo
 
getClientId() - Method in class org.activemq.message.ConnectionInfo
 
getClientId() - Method in class org.activemq.message.ConsumerInfo
 
getClientId() - Method in class org.activemq.message.DurableUnsubscribe
 
getClientId() - Method in class org.activemq.message.ProducerInfo
 
getClientId() - Method in class org.activemq.message.SessionInfo
 
getClientID() - Method in class org.activemq.pool.PooledConnection
 
getClientId() - Method in class org.activemq.service.impl.SubscriptionImpl
 
getClientID() - Method in class org.activemq.service.SubscriberEntry
 
getClientId() - Method in interface org.activemq.service.Subscription
 
getClientID() - Method in interface org.activemq.transport.TransportChannel
 
getClientID() - Method in class org.activemq.transport.TransportChannelSupport
 
getClientVersion() - Method in class org.activemq.message.ConnectionInfo
 
getClockDaemon() - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
getClockDaemon() - Method in class org.activemq.store.journal.JournalPersistenceAdapter
 
getCloseCount() - Method in class org.activemq.management.JCAConnectionPoolStatsImpl
 
getClusterName() - Method in class org.activemq.message.BrokerInfo
 
getClusterName() - Method in class org.activemq.message.Receipt
 
getColumn() - Method in class org.activemq.selector.SimpleCharStream
Deprecated.  
getCommand() - Method in class org.activemq.message.BrokerAdminCommand
 
getCompressionLevel() - Method in class org.activemq.io.util.ByteArrayCompression
 
getCompressionLimit() - Method in class org.activemq.io.util.ByteArrayCompression
 
getCompressionStrategy() - Method in class org.activemq.io.util.ByteArrayCompression
 
getConfig() - Method in class org.activemq.spring.BrokerFactoryBean
 
getConnection() - Method in class org.activemq.pool.PooledConnection
 
getConnection() - Method in class org.activemq.pool.SessionPool
 
getConnection() - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
getConnection() - Method in class org.activemq.TransactionContext
 
getConnection() - Method in class org.activemq.util.JmsLogAppenderSupport
 
getConnectionFactory() - Method in class org.activemq.management.JCAConnectionStatsImpl
 
getConnectionFactory() - Method in class org.activemq.pool.PooledConnectionFactory
 
getConnectionFactoryNames(Map) - Method in class org.activemq.jndi.ActiveMQInitialContextFactory
 
getConnectionInfo() - Method in interface org.activemq.broker.BrokerClient
 
getConnectionInfo() - Method in class org.activemq.broker.impl.BrokerClientImpl
 
getConnectionMemoryLimit() - Method in class org.activemq.ActiveMQConnection
Get the current value for the maximum amount of memory this Connection should use for buffered inbound messages
getConnectionPools() - Method in class org.activemq.management.JCAStatsImpl
 
getConnectionPrefix() - Method in class org.activemq.jndi.ActiveMQInitialContextFactory
 
getConnections() - Method in class org.activemq.advisories.ConnectionAdvisor
Retrive all current Connections
getConnections() - Method in class org.activemq.management.JCAStatsImpl
 
getConnections() - Method in class org.activemq.management.JMSStatsImpl
 
getConnectionStats() - Method in class org.activemq.ActiveMQConnection
 
getConnectorByURL(String) - Method in class org.activemq.broker.BrokerContext
 
getConnectRoles() - Method in class org.activemq.security.jassjacc.BrokerSecurityConfig
 
getConsumerId() - Method in class org.activemq.message.ConsumerInfo
 
getConsumerId() - Method in class org.activemq.message.MessageAck
 
getConsumerId() - Method in class org.activemq.service.impl.SubscriptionImpl
 
getConsumerId() - Method in interface org.activemq.service.Subscription
 
getConsumerIdentifer() - Method in class org.activemq.message.ActiveMQMessage
 
getConsumerIdentifier() - Method in class org.activemq.ActiveMQMessageConsumer
 
getConsumerInfo() - Method in class org.activemq.service.boundedvm.DurableSubscription
 
getConsumerInfo() - Method in class org.activemq.service.boundedvm.TransientSubscription
 
getConsumerKey() - Method in class org.activemq.message.ConsumerInfo
Creates a primary key for the consumer info which uniquely describes the consumer using a combination of clientID and consumerName
getConsumerName() - Method in class org.activemq.ActiveMQMessageConsumer
 
getConsumerName() - Method in exception org.activemq.DuplicateDurableSubscriptionException
 
getConsumerName() - Method in class org.activemq.message.ConsumerInfo
 
getConsumerName() - Method in class org.activemq.service.SubscriberEntry
 
getConsumerNo() - Method in class org.activemq.message.ConsumerInfo
 
getConsumerNos() - Method in class org.activemq.message.ActiveMQMessage
 
getConsumerNosAsString() - Method in class org.activemq.message.ActiveMQMessage
 
getConsumerNumber() - Method in class org.activemq.ActiveMQMessageConsumer
 
getConsumerNumber() - Method in class org.activemq.service.impl.SubscriptionImpl
 
getConsumerNumber() - Method in interface org.activemq.service.Subscription
 
getConsumeRoles() - Method in class org.activemq.security.jassjacc.DestinationSecurityConfig
 
getConsumers() - Method in class org.activemq.management.JMSSessionStatsImpl
 
getConsumerStats() - Method in class org.activemq.ActiveMQMessageConsumer
 
getContainer(String, String) - Method in class org.activemq.ActiveMQConnectionFactory
 
getContainer(String) - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageManager
 
getContainer(String) - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageManager
 
getContainer(String) - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageManager
For Transient topics - a MessageContainer maps on to the messages to be dispatched through a BrokerClient, not a destination
getContainer(String) - Method in class org.activemq.service.impl.DurableQueueMessageContainerManager
 
getContainer(String) - Method in class org.activemq.service.impl.MessageContainerManagerSupport
 
getContainer(String) - Method in class org.activemq.service.impl.ProxyMessageContainerManager
 
getContainer(String) - Method in interface org.activemq.service.MessageContainerManager
Allows the lookup of a specific named message container
getContainerManagerMap() - Method in interface org.activemq.broker.Broker
 
getContainerManagerMap() - Method in class org.activemq.broker.impl.DefaultBroker
 
getContainerManagers() - Method in class org.activemq.broker.impl.DefaultBroker
 
getContainerNameDataType() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getContents() - Method in class org.activemq.io.util.MemoryBoundedPrioritizedQueue
Retrieve a shallow copy of the contents as a list
getContents() - Method in class org.activemq.io.util.MemoryBoundedQueue
Retrieve a shallow copy of the contents as a list
getContents() - Method in class org.activemq.io.util.SpooledBoundedActiveMQMessageQueue
 
getContexTransaction() - Static method in class org.activemq.service.TransactionManager
 
getCorrelationId() - Method in class org.activemq.message.CapacityInfo
 
getCorrelationId() - Method in class org.activemq.message.Receipt
 
getCount() - Method in class org.activemq.management.CountStatisticImpl
 
getCount() - Method in class org.activemq.management.TimeStatisticImpl
 
getCountFromId(String) - Static method in class org.activemq.util.IdGenerator
From a generated id - return the generator count
getCreateCount() - Method in class org.activemq.management.JCAConnectionPoolStatsImpl
 
getCreateDurableSubStatment() - Method in class org.activemq.store.jdbc.adapter.CachingStatementProvider
 
getCreateDurableSubStatment() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getCreateDurableSubStatment() - Method in interface org.activemq.store.jdbc.StatementProvider
 
getCreateSchemaStatments() - Method in class org.activemq.store.jdbc.adapter.CachingStatementProvider
 
getCreateSchemaStatments() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getCreateSchemaStatments() - Method in interface org.activemq.store.jdbc.StatementProvider
 
getCurrent() - Method in class org.activemq.management.RangeStatisticImpl
 
getCurrentCapacity() - Method in class org.activemq.capacity.BasicCapacityMonitor
Get the current capscity of the service as a percentage
getCurrentCapacity() - Method in interface org.activemq.capacity.CapacityMonitor
Get the current capacity of the service as a percentage
getCurrentCapacity() - Method in class org.activemq.capacity.DelegateCapacityMonitor
Get the current capscity of the service as a percentage
getCurrentCapacity() - Method in class org.activemq.io.util.MemoryBoundedQueueManager
 
getCurrentValue() - Method in class org.activemq.capacity.BasicCapacityMonitor
Get the current value of the CapacityMonitor
getCurrentValue() - Method in interface org.activemq.capacity.CapacityMonitor
Get the current value of the CapacityMonitor
getCurrentValue() - Method in class org.activemq.capacity.DelegateCapacityMonitor
Get the current value of the CapacityMonitor
getCurrentWireFormatVersion() - Method in class org.activemq.io.impl.AbstractDefaultWireFormat
 
getCurrentWireFormatVersion() - Method in interface org.activemq.io.WireFormat
 
getCurrentWireFormatVersion() - Method in class org.activemq.transport.activeio.ActiveIOTransportChannel
 
getCurrentWireFormatVersion() - Method in class org.activemq.transport.composite.CompositeTransportChannel
 
getCurrentWireFormatVersion() - Method in class org.activemq.transport.jabber.JabberWireFormat
 
getCurrentWireFormatVersion() - Method in class org.activemq.transport.stomp.StompWireFormat
 
getCurrentWireFormatVersion() - Method in class org.activemq.transport.tcp.TcpTransportChannel
 
getCurrentWireFormatVersion() - Method in interface org.activemq.transport.TransportChannel
 
getCurrentWireFormatVersion() - Method in class org.activemq.transport.TransportChannelSupport
 
getCurrentWireFormatVersion() - Method in class org.activemq.transport.udp.UdpTransportChannel
 
getCurrentWireFormatVersion() - Method in class org.activemq.transport.vm.VmTransportChannel
 
getData() - Method in class org.activemq.io.util.WireByteArrayOutputStream
 
getDataSource() - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
getDeadLetterName() - Method in class org.activemq.service.DeadLetterPolicy
 
getDeadLetterNameFromDestination(ActiveMQDestination) - Method in class org.activemq.service.DeadLetterPolicy
Get the name of the DLQ from the destination provided
getDeadLetterPolicy() - Method in interface org.activemq.broker.Broker
 
getDeadLetterPolicy() - Method in class org.activemq.broker.impl.BrokerContainerImpl
 
getDeadLetterPolicy() - Method in class org.activemq.broker.impl.DefaultBroker
 
getDeadLetterPolicy() - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageManager
 
getDeadLetterPolicy() - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageManager
 
getDeadLetterPolicy() - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageManager
 
getDeadLetterPolicy() - Method in class org.activemq.service.impl.MessageContainerManagerSupport
 
getDeadLetterPolicy() - Method in class org.activemq.service.impl.ProxyMessageContainerManager
 
getDeadLetterPolicy() - Method in class org.activemq.service.impl.SubscriptionContainerImpl
 
getDeadLetterPolicy() - Method in interface org.activemq.service.MessageContainerManager
 
getDeadLetterPolicy() - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
getDeadLetterPrefix() - Method in class org.activemq.service.DeadLetterPolicy
 
getDelegate() - Method in class org.activemq.service.impl.ProxyMessageContainerManager
 
getDelegate() - Method in class org.activemq.store.ProxyMessageStore
 
getDelegate() - Method in class org.activemq.store.ProxyTopicMessageStore
 
getDeleteExpiredMessages() - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
getDeleteMessageStatement() - Method in class org.activemq.store.jdbc.adapter.CachingStatementProvider
 
getDeleteMessageStatement() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getDeleteMessageStatement() - Method in interface org.activemq.store.jdbc.StatementProvider
 
getDeleteOldMessagesStatment() - Method in class org.activemq.store.jdbc.adapter.CachingStatementProvider
 
getDeleteOldMessagesStatment() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getDeleteOldMessagesStatment() - Method in interface org.activemq.store.jdbc.StatementProvider
 
getDeleteSubscriptionStatment() - Method in class org.activemq.store.jdbc.adapter.CachingStatementProvider
 
getDeleteSubscriptionStatment() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getDeleteSubscriptionStatment() - Method in interface org.activemq.store.jdbc.StatementProvider
 
getDeliveryCount() - Method in class org.activemq.message.ActiveMQMessage
 
getDeliveryListener() - Method in class org.activemq.ActiveMQSession
 
getDeliveryMode() - Method in class org.activemq.ActiveMQMessageProducer
Gets the producer's default delivery mode.
getDeliveryMode() - Method in class org.activemq.pool.PooledProducer
 
getDemandListener() - Method in class org.activemq.advisories.ProducerDemandAdvisor
 
getDescription() - Method in class org.activemq.management.StatisticImpl
 
getDesendentValues() - Method in class org.activemq.filter.DestinationMapNode
Returns a list of all the values from this node down the tree
getDestination() - Method in class org.activemq.ActiveMQMessageConsumer
 
getDestination() - Method in class org.activemq.ActiveMQMessageProducer
Gets the destination associated with this MessageProducer.
getDestination() - Method in class org.activemq.advisories.ProducerDemandEvent
 
getDestination() - Method in class org.activemq.advisories.TempDestinationAdvisoryEvent
 
getDestination() - Method in class org.activemq.management.JMSProducerStatsImpl
 
getDestination() - Method in class org.activemq.message.BrokerAdminCommand
 
getDestination() - Method in class org.activemq.message.ConsumerInfo
 
getDestination() - Method in class org.activemq.message.MessageAck
 
getDestination() - Method in class org.activemq.message.ProducerInfo
 
getDestination() - Method in class org.activemq.pool.PooledProducer
 
getDestination() - Method in class org.activemq.security.jassjacc.DestinationSecurityConfig
 
getDestination() - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageContainer
 
getDestination() - Method in class org.activemq.service.boundedvm.DurableSubscription
 
getDestination() - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
 
getDestination() - Method in class org.activemq.service.boundedvm.TransientSubscription
 
getDestination() - Method in class org.activemq.service.impl.SubscriptionImpl
 
getDestination() - Method in class org.activemq.service.SubscriberEntry
 
getDestination() - Method in interface org.activemq.service.Subscription
 
getDestination() - Method in class org.activemq.store.journal.JournalAck
 
getDestination(LoggingEvent) - Method in class org.activemq.util.JmsLogAppenderSupport
 
getDestinationBeingAdvised() - Method in class org.activemq.message.ActiveMQDestination
 
getDestinationContext(Hashtable) - Method in interface org.activemq.broker.Broker
Returns the naming context of the destinations available in this broker
getDestinationContext(Hashtable) - Method in class org.activemq.broker.impl.DefaultBroker
 
getDestinationFilter() - Method in class org.activemq.message.ActiveMQDestination
 
getDestinationName() - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageContainer
 
getDestinationName() - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
 
getDestinationName() - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
 
getDestinationName() - Method in class org.activemq.service.impl.DurableQueueMessageContainer
 
getDestinationName() - Method in class org.activemq.service.impl.DurableTopicMessageContainer
 
getDestinationName() - Method in interface org.activemq.service.MessageContainer
 
getDestinationName() - Method in interface org.activemq.service.MessageContainerAdmin
 
getDestinationPaths(String) - Static method in class org.activemq.filter.DestinationPath
 
getDestinationPaths(Message) - Static method in class org.activemq.filter.DestinationPath
 
getDestinationPaths(Destination) - Static method in class org.activemq.filter.DestinationPath
 
getDestinationPaths() - Method in class org.activemq.message.ActiveMQDestination
 
getDestinations() - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageManager
 
getDestinations() - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageManager
 
getDestinations() - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageManager
 
getDestinations() - Method in class org.activemq.service.impl.MessageContainerManagerSupport
 
getDestinations() - Method in class org.activemq.service.impl.ProxyMessageContainerManager
 
getDestinations() - Method in interface org.activemq.service.MessageContainerManager
Returns an unmodifiable map, indexed by String name, of all the Destination objects available in this container
getDestinationSecurityConfigs() - Method in class org.activemq.security.jassjacc.PropertiesConfigLoader
 
getDestinationType() - Method in class org.activemq.message.ActiveMQDestination
 
getDestinationType() - Method in class org.activemq.message.ActiveMQQueue
 
getDestinationType() - Method in class org.activemq.message.ActiveMQTemporaryQueue
 
getDestinationType() - Method in class org.activemq.message.ActiveMQTemporaryTopic
 
getDestinationType() - Method in class org.activemq.message.ActiveMQTopic
 
getDirectory() - Method in class org.activemq.store.journal.JournalPersistenceAdapter
 
getDisableMessageID() - Method in class org.activemq.ActiveMQMessageProducer
Gets an indication of whether message IDs are disabled.
getDisableMessageID() - Method in class org.activemq.pool.PooledProducer
 
getDisableMessageTimestamp() - Method in class org.activemq.ActiveMQMessageProducer
Gets an indication of whether message timestamps are disabled.
getDisableMessageTimestamp() - Method in class org.activemq.pool.PooledProducer
 
getDiscoveryAgent() - Method in interface org.activemq.broker.BrokerContainer
Returns the discovery agent if one is available or null if discovery is not enabled
getDiscoveryAgent() - Method in class org.activemq.broker.impl.BrokerContainerImpl
 
getDiscoveryAgent() - Method in class org.activemq.transport.DiscoveryTransportChannel
 
getDiscoveryAgent() - Method in class org.activemq.transport.DiscoveryTransportChannelFactorySupport
 
getDiscoveryURI() - Method in class org.activemq.transport.peer.PeerTransportChannel
 
getDouble(String) - Method in class org.activemq.message.ActiveMQMapMessage
Returns the double value with the specified name.
getDoubleProperty(String) - Method in class org.activemq.message.ActiveMQMessage
Returns the value of the double property with the specified name.
getDropSchemaStatments() - Method in class org.activemq.store.jdbc.adapter.CachingStatementProvider
 
getDropSchemaStatments() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getDropSchemaStatments() - Method in interface org.activemq.store.jdbc.StatementProvider
 
getDropTablesOnStartup() - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
getDurableSubAcksTableName() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getDurableSubscriptionCount() - Method in class org.activemq.management.JMSSessionStatsImpl
 
getDurableTopicPrefetch() - Method in class org.activemq.ActiveMQPrefetchPolicy
 
getElement() - Method in class org.activemq.service.impl.DefaultQueueListEntry
Get the Object value for this entry
getElement() - Method in class org.activemq.service.impl.QueueListSupport.Node
 
getElement() - Method in interface org.activemq.service.QueueListEntry
Get the Object value for this entry
getEmbeddedBroker() - Method in class org.activemq.ActiveMQConnectionFactory
 
getEmbeddedBrokerConnector() - Method in class org.activemq.transport.peer.PeerTransportChannel
Some transports that rely on an embedded broker need to create the connector used by the broker
getEmbeddedBrokerConnector() - Method in class org.activemq.transport.remote.RemoteTransportChannel
Some transports that rely on an embedded broker need to create the connector used by the broker
getEmbeddedBrokerConnector() - Method in interface org.activemq.transport.TransportChannel
Some transports that rely on an embedded broker need to create the connector used by the broker
getEmbeddedBrokerConnector() - Method in class org.activemq.transport.TransportChannelSupport
Some transports that rely on an embedded broker need to create the connector used by the broker
getEndColumn() - Method in class org.activemq.selector.SimpleCharStream
 
getEndLine() - Method in class org.activemq.selector.SimpleCharStream
 
getEntryBrokerName() - Method in class org.activemq.message.ActiveMQMessage
 
getEntryClusterName() - Method in class org.activemq.message.ActiveMQMessage
 
getEnumeration() - Method in class org.activemq.ActiveMQQueueBrowser
Gets an enumeration for browsing the current queue messages in the order they would be received.
getEnvironment() - Method in class org.activemq.jndi.ReadOnlyContext
 
getEstablishConnectionTimeout() - Method in class org.activemq.transport.composite.CompositeTransportChannel
Return the maximum amount of time spent trying to establish a connection or a negative number to keep going forever
getEstablishedChannel(long) - Method in class org.activemq.transport.reliable.ReliableTransportChannel
 
getException() - Method in class org.activemq.message.Receipt
 
getExceptionAsString() - Method in class org.activemq.message.Receipt
OpenWire helper method
getExceptionListener() - Method in class org.activemq.ActiveMQConnection
Gets the ExceptionListener object for this connection.
getExceptionListener() - Method in class org.activemq.pool.PooledConnection
 
getExceptionListener() - Method in class org.activemq.transport.TransportChannelSupport
 
getExceptionListener() - Method in class org.activemq.util.MessageListenerSupport
 
getExpiredMessageCount() - Method in class org.activemq.management.JMSEndpointStatsImpl
 
getExpiredMessageCount() - Method in class org.activemq.management.JMSSessionStatsImpl
 
getExpression() - Method in class org.activemq.filter.ExpressionFilter
 
getExpressionSymbol() - Method in class org.activemq.filter.BinaryExpression
Returns the symbol that represents this binary expression.
getExpressionSymbol() - Method in class org.activemq.filter.MultiExpressionEvaluator.CacheExpression
 
getExpressionSymbol() - Method in class org.activemq.filter.UnaryExpression
Returns the symbol that represents this binary expression.
getFactory(URI) - Static method in class org.activemq.transport.TransportChannelProvider
 
getFactory(String) - Static method in class org.activemq.transport.TransportServerChannelProvider
 
getFactoryStats() - Method in class org.activemq.ActiveMQConnectionFactory
 
getFailureSleepTime() - Method in class org.activemq.transport.composite.CompositeTransportChannel
 
getFilter() - Method in class org.activemq.service.boundedvm.DurableSubscription
 
getFilter() - Method in class org.activemq.service.boundedvm.TransientSubscription
 
getFilter() - Method in class org.activemq.service.impl.SubscriptionImpl
 
getFindAllDurableSubMessagesStatment() - Method in class org.activemq.store.jdbc.adapter.CachingStatementProvider
 
getFindAllDurableSubMessagesStatment() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getFindAllDurableSubMessagesStatment() - Method in interface org.activemq.store.jdbc.StatementProvider
 
getFindAllMessagesStatment() - Method in class org.activemq.store.jdbc.adapter.CachingStatementProvider
 
getFindAllMessagesStatment() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getFindAllMessagesStatment() - Method in interface org.activemq.store.jdbc.StatementProvider
 
getFindAllXidStatment() - Method in class org.activemq.store.jdbc.adapter.CachingStatementProvider
 
getFindAllXidStatment() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getFindAllXidStatment() - Method in interface org.activemq.store.jdbc.StatementProvider
 
getFindDurableSubStatment() - Method in class org.activemq.store.jdbc.adapter.CachingStatementProvider
 
getFindDurableSubStatment() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getFindDurableSubStatment() - Method in interface org.activemq.store.jdbc.StatementProvider
 
getFindExpiredMessagesStatment() - Method in class org.activemq.store.jdbc.adapter.CachingStatementProvider
 
getFindExpiredMessagesStatment() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getFindExpiredMessagesStatment() - Method in interface org.activemq.store.jdbc.StatementProvider
 
getFindLastSequenceIdInAcks() - Method in class org.activemq.store.jdbc.adapter.CachingStatementProvider
 
getFindLastSequenceIdInAcks() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getFindLastSequenceIdInAcks() - Method in interface org.activemq.store.jdbc.StatementProvider
 
getFindLastSequenceIdInMsgs() - Method in class org.activemq.store.jdbc.adapter.CachingStatementProvider
 
getFindLastSequenceIdInMsgs() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getFindLastSequenceIdInMsgs() - Method in interface org.activemq.store.jdbc.StatementProvider
 
getFindMessageAttributesForUpdateStatment() - Method in class org.activemq.store.jdbc.adapter.CachingStatementProvider
 
getFindMessageAttributesForUpdateStatment() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getFindMessageAttributesForUpdateStatment() - Method in interface org.activemq.store.jdbc.StatementProvider
 
getFindMessageAttributesStatment() - Method in class org.activemq.store.jdbc.adapter.CachingStatementProvider
 
getFindMessageAttributesStatment() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getFindMessageAttributesStatment() - Method in interface org.activemq.store.jdbc.StatementProvider
 
getFindMessageSequenceIdStatment() - Method in class org.activemq.store.jdbc.adapter.CachingStatementProvider
 
getFindMessageSequenceIdStatment() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getFindMessageSequenceIdStatment() - Method in interface org.activemq.store.jdbc.StatementProvider
 
getFindMessageStatment() - Method in class org.activemq.store.jdbc.adapter.CachingStatementProvider
 
getFindMessageStatment() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getFindMessageStatment() - Method in interface org.activemq.store.jdbc.StatementProvider
 
getFirst() - Method in class org.activemq.service.impl.DefaultQueueList
 
getFirst() - Method in class org.activemq.service.impl.QueueListSupport
 
getFirst() - Method in interface org.activemq.service.QueueList
Returns the first element in this list.
getFirstEntry() - Method in class org.activemq.service.impl.DefaultQueueList
 
getFirstEntry() - Method in class org.activemq.service.impl.QueueListSupport
 
getFirstEntry() - Method in interface org.activemq.service.QueueList
Retrieve the first entry for the linked list
getFirstException() - Method in class org.activemq.util.ExceptionTemplate
Returns the first exception thrown during the execution of this template or returns null if there has been no exception thrown yet.
getFloat(String) - Method in class org.activemq.message.ActiveMQMapMessage
Returns the float value with the specified name.
getFloatProperty(String) - Method in class org.activemq.message.ActiveMQMessage
Returns the value of the float property with the specified name.
getFlowControlTimeout() - Method in class org.activemq.message.CapacityInfo
 
getFormatId() - Method in class org.activemq.message.ActiveMQXid
 
getFragmentation() - Method in class org.activemq.ActiveMQConnection
 
getFragmentationLimit() - Method in class org.activemq.io.util.ByteArrayFragmentation
 
getFreePoolSize() - Method in class org.activemq.management.JCAConnectionPoolStatsImpl
 
getGarbageCoolectionCapacityLimit() - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageManager
 
getGarbageCoolectionCapacityLimit() - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageManager
 
getGlobalTransactionId() - Method in class org.activemq.message.ActiveMQXid
 
getGrowthLimit() - Method in class org.activemq.io.util.MemoryBoundedMessageCache
 
getHeader() - Method in class org.activemq.service.impl.QueueListSupport
Looks up the header object, lazily creating one if the current table is empty
getHighWaterMark() - Method in class org.activemq.management.RangeStatisticImpl
 
getHostName() - Method in class org.activemq.message.ConnectionInfo
 
getHostName() - Static method in class org.activemq.util.IdGenerator
As we have to find the hostname as a side-affect of generating a unique stub, we allow it's easy retrevial here
getId() - Method in class org.activemq.message.AbstractPacket
 
getId() - Method in interface org.activemq.message.Packet
 
getIdGenerator() - Method in class org.activemq.ActiveMQMessageProducer
 
getIdleTimestamp() - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageContainer
 
getIdleTimestamp() - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
 
GetImage() - Method in class org.activemq.selector.SimpleCharStream
 
getInactiveTimeout() - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageManager
 
getInactiveTimeout() - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageManager
 
getIndentLevel() - Method in class org.activemq.util.IndentPrinter
 
getInfo() - Method in class org.activemq.advisories.ConnectionAdvisoryEvent
 
getInfo() - Method in class org.activemq.advisories.ConsumerAdvisoryEvent
 
getInfo() - Method in class org.activemq.advisories.ProducerAdvisoryEvent
 
getInitialContext(Hashtable) - Method in class org.activemq.jndi.ActiveMQInitialContextFactory
 
getInitialContext(Hashtable) - Method in class org.activemq.jndi.ActiveMQWASInitialContextFactory
 
getInitialContextFactoryName() - Method in class org.activemq.util.JndiJmsLogAppender
 
getInitialDestinations() - Method in class org.activemq.store.cache.CachePersistenceAdapter
 
getInitialDestinations() - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
getInitialDestinations() - Method in class org.activemq.store.journal.JournalPersistenceAdapter
 
getInitialDestinations() - Method in interface org.activemq.store.PersistenceAdapter
Returns a map, indexed by String name, of all the Destination objects active on startup.
getInitialDestinations() - Method in class org.activemq.store.vm.VMPersistenceAdapter
 
getInitializedClientID() - Method in class org.activemq.ActiveMQConnection
Returns the clientID of the connection, forcing one to be generated if one has not yet been configured
getInitialRedeliveryTimeout() - Method in class org.activemq.service.RedeliveryPolicy
Returns the initial redelivery timeout
getInstance() - Static method in class org.activemq.broker.BrokerContext
 
getInstance() - Static method in class org.activemq.transport.reliable.KeepAliveDaemon
Gets the current instance.
getInt(String) - Method in class org.activemq.message.ActiveMQMapMessage
Returns the int value with the specified name.
getInt(Map, String, int) - Static method in class org.activemq.util.MapHelper
Extracts the value from the map and coerces to an int value or returns a default value if one could not be found or coerced
getIntProperty(String) - Method in class org.activemq.message.ActiveMQMessage
Returns the value of the int property with the specified name.
getJabberWireFormat() - Method in class org.activemq.transport.jabber.JabberTransportChannel
 
getJDBCAdapter() - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
getJMSActiveMQDestination() - Method in class org.activemq.message.ActiveMQMessage
 
getJMSClientID() - Method in class org.activemq.message.ActiveMQMessage
 
getJMSCorrelationID() - Method in class org.activemq.message.ActiveMQMessage
Gets the correlation ID for the message.
getJMSCorrelationIDAsBytes() - Method in class org.activemq.message.ActiveMQMessage
Gets the correlation ID as an array of bytes for the message.
getJMSDeliveryMode() - Method in class org.activemq.message.ActiveMQMessage
Gets the DeliveryMode value specified for this message.
getJMSDestination() - Method in class org.activemq.message.ActiveMQMessage
Gets the Destination object for this message.
getJMSExpiration() - Method in class org.activemq.message.ActiveMQMessage
Gets the message's expiration value.
getJMSMajorVersion() - Method in class org.activemq.ActiveMQConnectionMetaData
Gets the JMS major version number.
getJMSMessageID() - Method in class org.activemq.message.ActiveMQMessage
Gets the message ID.
getJMSMessageIdentity() - Method in class org.activemq.message.ActiveMQMessage
 
getJMSMinorVersion() - Method in class org.activemq.ActiveMQConnectionMetaData
Gets the JMS minor version number.
getJMSPriority() - Method in class org.activemq.message.ActiveMQMessage
Gets the message priority level.
getJMSProviderName() - Method in class org.activemq.ActiveMQConnectionMetaData
Gets the JMS provider name.
getJMSRedelivered() - Method in class org.activemq.message.ActiveMQMessage
Gets an indication of whether this message is being redelivered.
getJMSReplyTo() - Method in class org.activemq.message.ActiveMQMessage
Gets the Destination object to which a reply to this message should be sent.
getJMSTimestamp() - Method in class org.activemq.message.ActiveMQMessage
Gets the message timestamp.
getJMSType() - Method in class org.activemq.message.ActiveMQMessage
Gets the message type identifier supplied by the client when the message was sent.
getJMSVersion() - Method in class org.activemq.ActiveMQConnectionMetaData
Gets the JMS API version.
getJMSXPropertyNames() - Method in class org.activemq.ActiveMQConnectionMetaData
Gets an enumeration of the JMSX property names.
getJndiName() - Method in class org.activemq.util.JndiJmsLogAppender
 
getJournalType() - Method in class org.activemq.store.journal.JournalPersistenceAdapter
 
getKeepAliveTimeout() - Method in class org.activemq.transport.multicast.MulticastDiscoveryAgent
 
getKeepAliveTimeout() - Method in class org.activemq.transport.reliable.ReliableTransportChannel
 
getLast() - Method in class org.activemq.service.impl.DefaultQueueList
 
getLast() - Method in class org.activemq.service.impl.QueueListSupport
 
getLast() - Method in interface org.activemq.service.QueueList
Returns the last element in this list.
getLastCheckTime() - Method in class org.activemq.transport.reliable.KeepAliveDaemon
 
getLastEntry() - Method in class org.activemq.service.impl.DefaultQueueList
 
getLastEntry() - Method in class org.activemq.service.impl.QueueListSupport
 
getLastEntry() - Method in interface org.activemq.service.QueueList
Retrieve the last entry for the linked list
getLastestMessageIdentity() - Method in class org.activemq.store.cache.CacheTopicMessageStore
 
getLastestMessageIdentity() - Method in class org.activemq.store.jdbc.JDBCTopicMessageStore
 
getLastestMessageIdentity() - Method in class org.activemq.store.journal.JournalTopicMessageStore
 
getLastestMessageIdentity() - Method in class org.activemq.store.ProxyTopicMessageStore
 
getLastestMessageIdentity() - Method in interface org.activemq.store.TopicMessageStore
Returns the last message identity that was delivered on this container which can then be used as a checkpoint so that when new durable consumers start, we know where to checkpoint their subscriptions.
getLastestMessageIdentity() - Method in class org.activemq.store.vm.VMTopicMessageStore
 
getLastMessageIdentity() - Method in class org.activemq.service.impl.SubscriptionImpl
 
getLastMessageIdentity() - Method in interface org.activemq.service.Subscription
Retreives the messageIdentity of the last message sent to this Queue based Subscription
getLastPath(URI) - Static method in class org.activemq.util.URIHelper
Get the Path
getLastQuery(URI) - Static method in class org.activemq.util.URIHelper
Get the query str
getLastReceiptTimestamp() - Method in class org.activemq.transport.composite.CompositeTransportChannel
 
getLastReceiptTimestamp() - Method in interface org.activemq.transport.TransportChannel
Gets the timestamp of the last received receipt packet.
getLastReceiptTimestamp() - Method in class org.activemq.transport.TransportChannelSupport
 
getLastSampleTime() - Method in class org.activemq.management.StatisticImpl
 
getLastSequenceId() - Method in class org.activemq.util.LongSequenceGenerator
 
getLeft() - Method in class org.activemq.filter.AndFilter
 
getLeft() - Method in class org.activemq.filter.BinaryExpression
 
getLeft() - Method in class org.activemq.filter.OrFilter
 
getLength() - Method in class org.activemq.io.util.ByteArray
 
getLine() - Method in class org.activemq.selector.SimpleCharStream
Deprecated.  
getLocalBrokerName() - Method in class org.activemq.broker.impl.BrokerContainerImpl
 
getLocalBrokerName() - Method in class org.activemq.transport.DiscoveryNetworkConnector
 
getLocalConnectionURL() - Method in class org.activemq.broker.impl.BrokerContainerImpl
 
getLocalDestinations() - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageManager
Returns an unmodifiable map, indexed by String name, of all the Destination objects used by non-broker consumers directly connected to this container
getLocalDestinations() - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageManager
Returns an unmodifiable map, indexed by String name, of all the Destination objects used by non-broker consumers directly connected to this container
getLocalDestinations() - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageManager
Returns an unmodifiable map, indexed by String name, of all the Destination objects used by non-broker consumers directly connected to this container
getLocalDestinations() - Method in class org.activemq.service.impl.DurableQueueMessageContainerManager
Returns an unmodifiable map, indexed by String name, of all the Destination objects used by non-broker consumers directly connected to this container
getLocalDestinations() - Method in class org.activemq.service.impl.DurableTopicMessageContainerManager
Returns an unmodifiable map, indexed by String name, of all the Destination objects used by non-broker consumers directly connected to this container
getLocalDestinations() - Method in class org.activemq.service.impl.ProxyMessageContainerManager
 
getLocalDestinations() - Method in interface org.activemq.service.MessageContainerManager
Returns an unmodifiable map, indexed by String name, of all the Destination objects used by non-broker consumers directly connected to this container
getLocalDetails() - Method in class org.activemq.transport.NetworkConnector
 
getLocalDurableTopicPrefetch() - Method in class org.activemq.transport.NetworkConnector
 
getLocalId() - Method in class org.activemq.transport.multicast.MulticastDiscoveryAgent
 
getLocalId() - Method in class org.activemq.transport.multicast.MulticastTester
 
getLocalMemoryUsage() - Method in class org.activemq.ActiveMQMessageConsumer
 
getLocalMemoryUsedByThisQueue() - Method in class org.activemq.io.util.MemoryBoundedQueue
 
getLocalPrefetchPolicy() - Method in class org.activemq.transport.NetworkChannel
 
getLocalPrefetchPolicy() - Method in class org.activemq.transport.NetworkConnector
 
getLocalQueueBrowserPrefetch() - Method in class org.activemq.transport.NetworkConnector
 
getLocalQueuePrefetch() - Method in class org.activemq.transport.NetworkConnector
 
getLocalTopicPrefetch() - Method in class org.activemq.transport.NetworkConnector
 
getLocalTransaction(String) - Method in class org.activemq.service.impl.TransactionManagerImpl
 
getLocalTransaction(String) - Method in class org.activemq.service.TransactionManager
 
getLocalTransactionEventListener() - Method in class org.activemq.TransactionContext
 
getLogFileCount() - Method in class org.activemq.store.journal.JournalPersistenceAdapter
 
getLogFileSize() - Method in class org.activemq.store.journal.JournalPersistenceAdapter
 
getLong(String) - Method in class org.activemq.message.ActiveMQMapMessage
Returns the long value with the specified name.
getLongDataType() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getLongProperty(String) - Method in class org.activemq.message.ActiveMQMessage
Returns the value of the long property with the specified name.
getLongTermMessageStore() - Method in class org.activemq.store.journal.JournalMessageStore
 
getLongTermPersistence() - Method in class org.activemq.store.cache.CachePersistenceAdapter
 
getLongTermPersistence() - Method in class org.activemq.store.journal.JournalPersistenceAdapter
 
getLongTermStore() - Method in class org.activemq.store.cache.CacheMessageStore
 
getLongTermTopicMessageStore() - Method in class org.activemq.store.journal.JournalTopicMessageStore
 
getLowerBound() - Method in class org.activemq.management.BoundaryStatisticImpl
 
getLowerBound() - Method in class org.activemq.management.BoundedRangeStatisticImpl
 
getLowWaterMark() - Method in class org.activemq.management.RangeStatisticImpl
 
getManagedConnectionFactory() - Method in class org.activemq.management.JCAConnectionStatsImpl
 
getMapNames() - Method in class org.activemq.message.ActiveMQMapMessage
Returns an Enumeration of all the names in the MapMessage object.
getMaximumMemoryUsage() - Method in class org.activemq.broker.impl.DefaultBroker
 
getMaximumRetries() - Method in class org.activemq.transport.composite.CompositeTransportChannel
 
getMaximumRetries() - Method in class org.activemq.transport.NetworkChannel
 
getMaximumRetryCount() - Method in class org.activemq.service.RedeliveryPolicy
Returns the maximum retry count on a single message before its forwarded to a Dead Letter Queue
getMaximumTimeout() - Method in class org.activemq.transport.composite.CompositeTransportChannel
 
getMaxOutstandingMessages() - Method in class org.activemq.transport.tcp.TcpTransportServerChannel
 
getMaxTime() - Method in class org.activemq.management.TimeStatisticImpl
 
getMemoryBoundedQueue(String) - Method in class org.activemq.ActiveMQConnection
 
getMemoryBoundedQueue(String) - Method in class org.activemq.io.util.MemoryBoundedQueueManager
retrieve a named MemoryBoundedQueue or creates one if not found
getMemoryBoundedQueues() - Method in class org.activemq.io.util.MemoryBoundedQueueManager
 
getMemoryId() - Method in interface org.activemq.io.util.MemoryManageable
Get an id that can be used to identify the object.
getMemoryId() - Method in class org.activemq.message.ActiveMQMessage
Another way to get the Message id.
getMemoryId() - Method in class org.activemq.service.boundedvm.DurableMessagePointer
 
getMemoryManager() - Method in class org.activemq.broker.impl.DefaultBroker
 
getMemoryManager() - Method in class org.activemq.io.util.MemoryBoundedQueueManager
 
getMemoryManager() - Method in class org.activemq.store.cache.MemoryBoundedCachePersistenceAdapter
 
getMemoryUsage() - Method in interface org.activemq.io.util.MemoryManageable
Get a hint about how much memory this Packet is consuming
getMemoryUsage() - Method in class org.activemq.message.AbstractPacket
Get a hint about how much memory this Packet is consuming
getMemoryUsage() - Method in interface org.activemq.message.Packet
Get a hint about how much memory this Packet is consuming
getMemoryUsage() - Method in class org.activemq.service.boundedvm.DurableMessagePointer
 
getMemoryUsageReferenceCount() - Method in interface org.activemq.io.util.MemoryManageable
 
getMemoryUsageReferenceCount() - Method in class org.activemq.message.AbstractPacket
 
getMemoryUsageReferenceCount() - Method in interface org.activemq.message.Packet
 
getMemoryUsageReferenceCount() - Method in class org.activemq.service.boundedvm.DurableMessagePointer
 
getMessage() - Method in exception org.activemq.selector.ParseException
This method has the standard behavior when this object has been created using the standard constructors.
getMessage() - Method in error org.activemq.selector.TokenMgrError
You can also modify the body of this method to customize your error messages.
getMessage() - Method in class org.activemq.service.boundedvm.DurableMessagePointer
 
getMessage(MessageIdentity) - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
 
getMessage(MessageIdentity) - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
 
getMessage(MessageIdentity) - Method in class org.activemq.service.impl.DurableQueueMessageContainer
 
getMessage(MessageIdentity) - Method in class org.activemq.service.impl.DurableTopicMessageContainer
 
getMessage() - Method in class org.activemq.service.impl.MessageEntry
 
getMessage(MessageIdentity) - Method in interface org.activemq.service.MessageContainer
Return the ActiveMQMessage that matches the Id
getMessage(MessageIdentity) - Method in class org.activemq.store.cache.CacheMessageStore
Return the message from the cache or go to the longTermStore if it is not in there.
getMessage(MessageIdentity) - Method in class org.activemq.store.jdbc.JDBCMessageStore
 
getMessage(MessageIdentity) - Method in class org.activemq.store.journal.JournalMessageStore
 
getMessage() - Method in interface org.activemq.store.journal.JournalTransactionStore.AddMessageCommand
 
getMessage(MessageIdentity) - Method in interface org.activemq.store.MessageStore
Looks up a message using either the String messageID or the messageNumber.
getMessage(MessageIdentity) - Method in class org.activemq.store.ProxyMessageStore
 
getMessage(MessageIdentity) - Method in class org.activemq.store.ProxyTopicMessageStore
 
getMessage(MessageIdentity) - Method in class org.activemq.store.vm.VMMessageStore
 
getMessage() - Method in interface org.activemq.store.vm.VMTransactionStore.AddMessageCommand
 
getMessageAck() - Method in interface org.activemq.store.journal.JournalTransactionStore.RemoveMessageCommand
 
getMessageAck() - Method in interface org.activemq.store.vm.VMTransactionStore.RemoveMessageCommand
 
getMessageAcknowledge() - Method in class org.activemq.message.ActiveMQMessage
 
getMessageCompressionLevel() - Method in class org.activemq.ActiveMQConnection
 
getMessageCompressionLimit() - Method in class org.activemq.ActiveMQConnection
 
getMessageCompressionLimit() - Method in class org.activemq.ActiveMQConnectionFactory
 
getMessageCompressionStrategy() - Method in class org.activemq.ActiveMQConnection
 
getMessageCompressionStrategy() - Method in class org.activemq.ActiveMQConnectionFactory
 
getMessageContainerAdmin(ActiveMQDestination) - Method in interface org.activemq.broker.BrokerAdmin
 
getMessageContainerAdmin(ActiveMQDestination) - Method in class org.activemq.broker.impl.DefaultBroker
 
getMessageContainerAdmin() - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageContainer
 
getMessageContainerAdmin() - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
 
getMessageContainerAdmin() - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
 
getMessageContainerAdmin() - Method in class org.activemq.service.impl.DurableQueueMessageContainer
 
getMessageContainerAdmin() - Method in class org.activemq.service.impl.DurableTopicMessageContainer
 
getMessageContainerAdmin() - Method in interface org.activemq.service.MessageContainer
 
getMessageContainerAdmins() - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageManager
 
getMessageContainerAdmins() - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageManager
 
getMessageContainerAdmins() - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageManager
 
getMessageContainerAdmins() - Method in class org.activemq.service.impl.MessageContainerManagerSupport
 
getMessageContainerAdmins() - Method in class org.activemq.service.impl.ProxyMessageContainerManager
 
getMessageContainerAdmins() - Method in interface org.activemq.service.MessageContainerManager
Returns an unmodifiable map, indexed by ActiveMQDestination, of all the MessageContainerAdmin objects available in this container
getMessageCount() - Method in class org.activemq.management.JMSEndpointStatsImpl
 
getMessageCount() - Method in class org.activemq.management.JMSSessionStatsImpl
 
getMessageFragmentationLimit() - Method in class org.activemq.ActiveMQConnection
 
getMessageFragmentationLimit() - Method in class org.activemq.ActiveMQConnectionFactory
 
getMessageID() - Method in class org.activemq.message.MessageAck
 
getMessageID() - Method in class org.activemq.service.MessageIdentity
 
getMessageId() - Method in class org.activemq.store.journal.JournalAck
 
getMessageIdentity() - Method in class org.activemq.message.MessageAck
 
getMessageListener() - Method in class org.activemq.ActiveMQMessageConsumer
Gets the message consumer's MessageListener.
getMessageListener() - Method in class org.activemq.ActiveMQQueueSession
 
getMessageListener() - Method in class org.activemq.ActiveMQSession
Returns the session's distinguished message listener (optional).
getMessageListener() - Method in class org.activemq.ActiveMQTopicSession
 
getMessageListener() - Method in class org.activemq.pool.PooledSession
 
getMessageProducer() - Method in class org.activemq.pool.PooledProducer
 
getMessageProducer() - Method in class org.activemq.pool.PooledSession
 
getMessageRateTime() - Method in class org.activemq.management.JMSEndpointStatsImpl
 
getMessageRateTime() - Method in class org.activemq.management.JMSSessionStatsImpl
 
getMessages() - Method in class org.activemq.store.journal.JournalTransactionStore.Tx
 
getMessages() - Method in class org.activemq.store.vm.VMTransactionStore.Tx
 
getMessageSelector() - Method in class org.activemq.ActiveMQMessageConsumer
Gets this message consumer's message selector expression.
getMessageSelector() - Method in class org.activemq.ActiveMQQueueBrowser
 
getMessageSequenceId(Connection, String) - Method in class org.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
getMessageSequenceId(Connection, String) - Method in interface org.activemq.store.jdbc.JDBCAdapter
 
getMessageSequenceId(MessageIdentity) - Method in class org.activemq.store.jdbc.JDBCMessageStore
 
getMessagesToDispatch() - Method in class org.activemq.service.impl.SubscriptionImpl
Retrieve messages to dispatch
getMessagesToDispatch() - Method in interface org.activemq.service.Subscription
Retrieve messages to dispatch
getMessageStore() - Method in class org.activemq.service.boundedvm.DurableMessagePointer
 
getMessagesWithPrefetch() - Method in class org.activemq.service.impl.SubscriptionImpl
 
getMessageTableName() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getMessageWaitTime() - Method in class org.activemq.management.JMSEndpointStatsImpl
 
getMessageWaitTime() - Method in class org.activemq.management.JMSSessionStatsImpl
 
getMesssageHandle() - Method in class org.activemq.message.ActiveMQMessage
 
getMetaData() - Method in class org.activemq.ActiveMQConnection
Gets the metadata for this connection.
getMetaData() - Method in class org.activemq.pool.PooledConnection
 
getMinTime() - Method in class org.activemq.management.TimeStatisticImpl
 
getMonitorName() - Method in class org.activemq.capacity.CapacityMonitorEvent
 
getMsgIdDataType() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getName() - Method in class org.activemq.broker.impl.DefaultBroker
 
getName() - Method in class org.activemq.capacity.BasicCapacityMonitor
Get the name of the CapacityMonitor
getName() - Method in interface org.activemq.capacity.CapacityMonitor
Get the name of the CapacityMonitor
getName() - Method in class org.activemq.capacity.DelegateCapacityMonitor
Get the name of the CapacityMonitor
getName() - Method in class org.activemq.filter.PropertyExpression
 
getName() - Method in class org.activemq.io.util.MemoryBoundedQueue
 
getName() - Method in class org.activemq.io.util.SpooledBoundedActiveMQMessageQueue
 
getName() - Method in class org.activemq.management.StatisticImpl
 
getNameInNamespace() - Method in class org.activemq.jndi.ReadOnlyContext
 
getNameParser(Name) - Method in class org.activemq.jndi.ReadOnlyContext
 
getNameParser(String) - Method in class org.activemq.jndi.ReadOnlyContext
 
getNetworkChannels() - Method in class org.activemq.transport.NetworkConnector
 
getNetworkConnectors() - Method in interface org.activemq.broker.BrokerContainer
Returns a list of NetworkConnector instances used to communicate with the network of Broker instances
getNetworkConnectors() - Method in class org.activemq.broker.impl.BrokerContainerImpl
 
getNext() - Method in class org.activemq.ActiveMQQueueSession
 
getNext() - Method in class org.activemq.ActiveMQTopicSession
 
getNext() - Method in class org.activemq.store.jdbc.adapter.CachingStatementProvider
 
getNext() - Method in class org.activemq.util.URIHelper
 
getNextConsumerNumber() - Method in class org.activemq.ActiveMQConnection
 
getNextEntry(QueueListEntry) - Method in class org.activemq.service.impl.DefaultQueueList
 
getNextEntry(QueueListEntry) - Method in class org.activemq.service.impl.QueueListSupport
 
getNextEntry(QueueListEntry) - Method in interface org.activemq.service.QueueList
Retrieve the next entry after this entry
getNextSequence() - Method in class org.activemq.util.IdGenerator
 
getNextSequenceId() - Method in class org.activemq.util.LongSequenceGenerator
 
getNextSequenceNumber() - Method in class org.activemq.ActiveMQMessageProducer
 
getNextShortSequence() - Method in class org.activemq.util.IdGenerator
 
getNextThreadId() - Static method in class org.activemq.transport.vm.VmTransportChannel
 
getNextToken() - Method in class org.activemq.selector.SelectorParser
 
getNextToken() - Method in class org.activemq.selector.SelectorParserTokenManager
 
getNode(Long) - Method in class org.activemq.service.impl.QueueListSupport
 
getNode(int) - Method in class org.activemq.service.impl.QueueListSupport
 
getNode(QueueListSupport.Header, int) - Method in class org.activemq.service.impl.QueueListSupport
 
getNoLocal() - Method in class org.activemq.ActiveMQTopicSubscriber
Gets the NoLocal attribute for this subscriber.
getNumberOfParts() - Method in class org.activemq.message.ActiveMQMessage
 
getObject(String) - Method in class org.activemq.message.ActiveMQMapMessage
Returns the value of the object with the specified name.
getObject() - Method in class org.activemq.message.ActiveMQObjectMessage
Gets the serializable object containing this message's data.
getObject() - Method in class org.activemq.spring.BrokerFactoryBean
 
getObjectInstance(Object, Name, Context, Hashtable) - Method in class org.activemq.jndi.JNDIReferenceFactory
This will be called by a JNDIprovider when a Reference is retrieved from a JNDI store - and generates the orignal instance
getObjectProperty(String) - Method in class org.activemq.message.ActiveMQMessage
Returns the value of the Java object property with the specified name.
getObjectType() - Method in class org.activemq.spring.BrokerFactoryBean
 
getOffset() - Method in class org.activemq.io.util.ByteArray
 
getOperations() - Method in class org.activemq.store.journal.JournalTransactionStore.Tx
 
getOrderedTarget() - Method in class org.activemq.message.ActiveMQDestination
 
getOrigin() - Method in class org.activemq.management.JMSConsumerStatsImpl
 
getPacket() - Method in class org.activemq.message.PacketFacade
 
getPacketListener() - Method in class org.activemq.transport.TransportChannelSupport
 
getPacketType() - Method in class org.activemq.advisories.TempDestinationAdvisoryEvent
 
getPacketType() - Method in class org.activemq.io.impl.ActiveMQBytesMessageReader
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.ActiveMQBytesMessageWriter
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.ActiveMQMapMessageReader
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.ActiveMQMapMessageWriter
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.ActiveMQMessageReader
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.ActiveMQMessageWriter
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.ActiveMQObjectMessageReader
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.ActiveMQObjectMessageWriter
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.ActiveMQStreamMessageReader
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.ActiveMQStreamMessageWriter
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.ActiveMQTextMessageReader
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.ActiveMQTextMessageWriter
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.BrokerAdminCommandReader
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.BrokerAdminCommandWriter
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.BrokerInfoReader
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.BrokerInfoWriter
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.CachedValueReader
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.CachedValueWriter
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.CapacityInfoReader
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.CapacityInfoRequestReader
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.CapacityInfoRequestWriter
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.CapacityInfoWriter
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.CleanupConnectionInfoReader
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.CleanupConnectionInfoWriter
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.ConnectionInfoReader
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.ConnectionInfoWriter
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.ConsumerInfoReader
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.ConsumerInfoWriter
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.DurableUnsubscribeReader
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.DurableUnsubscribeWriter
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.IntResponseReceiptReader
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.IntResponseReceiptWriter
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.KeepAliveReader
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.KeepAliveWriter
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.MessageAckReader
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.MessageAckWriter
Return the type of Packet
getPacketType() - Method in interface org.activemq.io.impl.PacketReader
Return the type of Packet
getPacketType() - Method in interface org.activemq.io.impl.PacketWriter
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.ProducerInfoReader
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.ProducerInfoWriter
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.ReceiptReader
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.ReceiptWriter
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.ResponseReceiptReader
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.ResponseReceiptWriter
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.SessionInfoReader
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.SessionInfoWriter
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.TransactionInfoReader
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.TransactionInfoWriter
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.WireFormatInfoReader
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.WireFormatInfoWriter
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.XATransactionInfoReader
Return the type of Packet
getPacketType() - Method in class org.activemq.io.impl.XATransactionInfoWriter
Return the type of Packet
getPacketType() - Method in class org.activemq.message.ActiveMQBytesMessage
Return the type of Packet
getPacketType() - Method in class org.activemq.message.ActiveMQMapMessage
Return the type of Packet
getPacketType() - Method in class org.activemq.message.ActiveMQMessage
Return the type of Packet
getPacketType() - Method in class org.activemq.message.ActiveMQObjectMessage
Return the type of Packet
getPacketType() - Method in class org.activemq.message.ActiveMQStreamMessage
Return the type of Packet
getPacketType() - Method in class org.activemq.message.ActiveMQTextMessage
Return the type of Packet
getPacketType() - Method in class org.activemq.message.BrokerAdminCommand
Return the type of Packet
getPacketType() - Method in class org.activemq.message.BrokerInfo
Return the type of Packet
getPacketType() - Method in class org.activemq.message.CachedValue
Return the type of Packet
getPacketType() - Method in class org.activemq.message.CapacityInfo
 
getPacketType() - Method in class org.activemq.message.CapacityInfoRequest
 
getPacketType() - Method in class org.activemq.message.CleanupConnectionInfo
Return the type of Packet
getPacketType() - Method in class org.activemq.message.ConnectionInfo
Return the type of Packet
getPacketType() - Method in class org.activemq.message.ConsumerInfo
Return the type of Packet
getPacketType() - Method in class org.activemq.message.DurableUnsubscribe
Return the type of Packet
getPacketType() - Method in class org.activemq.message.IntResponseReceipt
 
getPacketType() - Method in class org.activemq.message.KeepAlive
Return the type of Packet
getPacketType() - Method in class org.activemq.message.MessageAck
Return the type of Packet
getPacketType() - Method in interface org.activemq.message.Packet
Return the type of Packet
getPacketType() - Method in class org.activemq.message.ProducerInfo
Return the type of Packet
getPacketType() - Method in class org.activemq.message.Receipt
Return the type of Packet
getPacketType() - Method in class org.activemq.message.ResponseReceipt
 
getPacketType() - Method in class org.activemq.message.SessionInfo
Return the type of Packet
getPacketType() - Method in class org.activemq.message.TransactionInfo
Return the type of Packet
getPacketType() - Method in class org.activemq.message.WireFormatInfo
Return the type of Packet
getPacketType() - Method in class org.activemq.message.XATransactionInfo
Return the type of Packet
getPacketType() - Method in class org.activemq.transport.stomp.FlushPacket
 
getPacketTypeAsString(int) - Static method in class org.activemq.message.AbstractPacket
 
getParent() - Method in class org.activemq.management.CountStatisticImpl
 
getParent() - Method in class org.activemq.management.TimeStatisticImpl
 
getParentMessageID() - Method in class org.activemq.message.ActiveMQMessage
 
getPartNumber() - Method in class org.activemq.message.ActiveMQMessage
 
getPassword() - Method in class org.activemq.ActiveMQConnectionFactory
 
getPassword() - Method in class org.activemq.message.ConnectionInfo
 
getPassword() - Method in class org.activemq.pool.ConnectionKey
 
getPassword() - Method in class org.activemq.util.JmsLogAppender
 
getPassword() - Method in class org.activemq.util.JndiJmsLogAppender
 
getPeerURIs() - Method in class org.activemq.transport.peer.PeerTransportChannel
 
getPendingMessageCount() - Method in class org.activemq.management.JMSEndpointStatsImpl
 
getPendingMessageCount() - Method in class org.activemq.management.JMSSessionStatsImpl
 
getPercentFull() - Method in class org.activemq.io.util.MemoryBoundedObjectManager
 
getPersistenceAdapter() - Method in interface org.activemq.broker.Broker
 
getPersistenceAdapter() - Method in interface org.activemq.broker.BrokerContainer
Returns the persistence adapter
getPersistenceAdapter() - Method in class org.activemq.broker.impl.BrokerContainerFactoryImpl
 
getPersistenceAdapter() - Method in class org.activemq.broker.impl.BrokerContainerImpl
 
getPersistenceAdapter() - Method in class org.activemq.broker.impl.DefaultBroker
 
getPersistentKey() - Method in class org.activemq.service.impl.DurableTopicSubscription
 
getPersistentKey() - Method in class org.activemq.service.impl.SubscriptionImpl
 
getPersistentKey() - Method in interface org.activemq.service.Subscription
Returns the persistent key used to uniquely identify this durable topic subscription
getPersistentQueueContainerManager() - Method in interface org.activemq.broker.Broker
 
getPersistentQueueContainerManager() - Method in class org.activemq.broker.impl.DefaultBroker
 
getPersistentTopicContainerManager() - Method in interface org.activemq.broker.Broker
 
getPersistentTopicContainerManager() - Method in class org.activemq.broker.impl.DefaultBroker
 
getPhysicalName() - Method in class org.activemq.message.ActiveMQDestination
 
getPoolSize() - Method in class org.activemq.management.JCAConnectionPoolStatsImpl
 
getPreferedWireFormat() - Method in class org.activemq.io.WireFormatLoader
 
getPrefetchNumber() - Method in class org.activemq.ActiveMQMessageConsumer
 
getPrefetchNumber() - Method in class org.activemq.message.ConsumerInfo
 
getPrefetchPolicy() - Method in class org.activemq.ActiveMQConnection
 
getPrefetchPolicy() - Method in class org.activemq.ActiveMQConnectionFactory
Allows the prefetch policy to be configured
getPreparedTransactions(BrokerClient) - Method in interface org.activemq.broker.Broker
gets a list of all the prepared xa transactions.
getPreparedTransactions(BrokerClient) - Method in interface org.activemq.broker.BrokerConnector
Get all the Xids of the prepared XA transactions.
getPreparedTransactions(BrokerClient) - Method in interface org.activemq.broker.BrokerContainer
Gets the prepared XA transactions.
getPreparedTransactions(BrokerClient) - Method in class org.activemq.broker.impl.BrokerConnectorImpl
Gets the prepared XA transactions.
getPreparedTransactions(BrokerClient) - Method in class org.activemq.broker.impl.BrokerContainerImpl
Gets the prepared XA transactions.
getPreparedTransactions(BrokerClient) - Method in class org.activemq.broker.impl.DefaultBroker
Gets the prepared XA transactions.
getPreparedTransactionStore() - Method in class org.activemq.broker.impl.DefaultBroker
 
getPreparedXATransactions() - Method in class org.activemq.service.impl.TransactionManagerImpl
 
getPreparedXATransactions() - Method in class org.activemq.service.TransactionManager
 
getPrevEntry(QueueListEntry) - Method in class org.activemq.service.impl.DefaultQueueList
 
getPrevEntry(QueueListEntry) - Method in class org.activemq.service.impl.QueueListSupport
 
getPrevEntry(QueueListEntry) - Method in interface org.activemq.service.QueueList
Retrive the previous entry after this entry
getPriority() - Method in class org.activemq.ActiveMQMessageProducer
Gets the producer's default priority.
getPriority() - Method in interface org.activemq.io.util.MemoryManageable
 
getPriority() - Method in class org.activemq.message.ActiveMQMessage
 
getPriority() - Method in class org.activemq.pool.PooledProducer
 
getPriority() - Method in class org.activemq.service.boundedvm.DurableMessagePointer
 
getProducer() - Method in class org.activemq.util.JmsLogAppenderSupport
 
getProducerId() - Method in class org.activemq.ActiveMQMessageProducer
 
getProducerId() - Method in class org.activemq.message.ProducerInfo
 
getProducerKey() - Method in class org.activemq.message.ActiveMQMessage
 
getProducerKey() - Method in class org.activemq.message.MessageAck
 
getProducerMessageKey() - Method in class org.activemq.ActiveMQMessageProducer
 
getProduceRoles() - Method in class org.activemq.security.jassjacc.DestinationSecurityConfig
 
getProducers() - Method in class org.activemq.management.JMSSessionStatsImpl
 
getProducerStats() - Method in class org.activemq.ActiveMQMessageProducer
 
getProperties() - Method in class org.activemq.jndi.JNDIBaseStorable
Get the properties from this instance for storing in JNDI
getProperties() - Method in interface org.activemq.jndi.JNDIStorableInterface
Get the properties from this instance for storing in JNDI
getProperties() - Method in class org.activemq.message.ActiveMQMessage
Retrieve the message properties as a Map
getProperties() - Method in class org.activemq.message.BrokerInfo
 
getProperties() - Method in class org.activemq.message.ConnectionInfo
 
getPropertyNames() - Method in class org.activemq.message.ActiveMQMessage
Returns an Enumeration of all the property names.
getProviderMajorVersion() - Method in class org.activemq.ActiveMQConnectionMetaData
Gets the JMS provider major version number.
getProviderMinorVersion() - Method in class org.activemq.ActiveMQConnectionMetaData
Gets the JMS provider minor version number.
getProviderURL() - Method in class org.activemq.util.JndiJmsLogAppender
 
getProviderVersion() - Method in class org.activemq.ActiveMQConnectionMetaData
Gets the JMS provider version.
getQueue() - Method in class org.activemq.ActiveMQQueueBrowser
Gets the queue associated with this queue browser.
getQueue() - Method in class org.activemq.ActiveMQQueueReceiver
Gets the Queue associated with this queue receiver.
getQueue() - Method in class org.activemq.ActiveMQQueueSender
Gets the queue associated with this QueueSender.
getQueue() - Method in class org.activemq.pool.PooledQueueSender
 
getQueueBrowserPrefetch() - Method in class org.activemq.ActiveMQPrefetchPolicy
 
getQueueManager() - Method in class org.activemq.broker.impl.DefaultBroker
 
getQueueName() - Method in class org.activemq.message.ActiveMQQueue
Gets the name of this queue.
getQueuePrefetch() - Method in class org.activemq.ActiveMQPrefetchPolicy
 
getQueuePrefix() - Method in class org.activemq.jndi.ActiveMQInitialContextFactory
 
getQueueSender() - Method in class org.activemq.pool.PooledQueueSender
 
getQueueSender() - Method in class org.activemq.pool.PooledSession
 
getQueueSession() - Method in class org.activemq.ActiveMQXASession
 
getRawData() - Method in class org.activemq.io.util.WireByteArrayInputStream
 
getReader() - Method in class org.activemq.spring.ActiveMQBeanFactory
 
getReceipt() - Method in class org.activemq.message.ReceiptHolder
Get the Receipt
getReceipt(int) - Method in class org.activemq.message.ReceiptHolder
wait upto timeout timeout ms to get a receipt
getReceiveCapacity() - Method in class org.activemq.transport.vm.VmTransportChannel
 
getReceiveChannel() - Method in class org.activemq.transport.vm.VmTransportChannel
 
getReconnectSleepTime() - Method in class org.activemq.transport.NetworkChannel
 
getRedeliveryPolicy() - Method in interface org.activemq.broker.Broker
 
getRedeliveryPolicy() - Method in class org.activemq.broker.impl.BrokerContainerImpl
 
getRedeliveryPolicy() - Method in class org.activemq.broker.impl.DefaultBroker
 
getRedeliveryPolicy() - Method in class org.activemq.service.impl.SubscriptionContainerImpl
 
getRedeliveryPolicy() - Method in class org.activemq.service.impl.SubscriptionImpl
 
getReference() - Method in class org.activemq.jndi.JNDIBaseStorable
Retrive a Reference for this instance to store in JNDI
getRemoteBrokerName() - Method in class org.activemq.transport.NetworkChannel
 
getRemoteDurableTopicPrefetch() - Method in class org.activemq.transport.NetworkConnector
 
getRemoteLocation() - Method in class org.activemq.transport.remote.RemoteTransportChannel
 
getRemotePassword() - Method in class org.activemq.transport.DiscoveryTransportChannel
 
getRemotePassword() - Method in class org.activemq.transport.NetworkChannel
 
getRemotePassword() - Method in class org.activemq.transport.NetworkConnector
 
getRemotePassword() - Method in class org.activemq.transport.peer.PeerTransportChannel
 
getRemotePassword() - Method in class org.activemq.transport.remote.RemoteTransportChannel
 
getRemotePrefetchPolicy() - Method in class org.activemq.transport.NetworkChannel
 
getRemotePrefetchPolicy() - Method in class org.activemq.transport.NetworkConnector
 
getRemoteQueueBrowserPrefetch() - Method in class org.activemq.transport.NetworkConnector
 
getRemoteQueuePrefetch() - Method in class org.activemq.transport.NetworkConnector
 
getRemoteTopicPrefetch() - Method in class org.activemq.transport.NetworkConnector
 
getRemoteURI() - Method in class org.activemq.transport.TransportStatusEvent
 
getRemoteUserName() - Method in class org.activemq.transport.DiscoveryTransportChannel
 
getRemoteUserName() - Method in class org.activemq.transport.NetworkChannel
 
getRemoteUserName() - Method in class org.activemq.transport.NetworkConnector
 
getRemoteUserName() - Method in class org.activemq.transport.peer.PeerTransportChannel
 
getRemoteUserName() - Method in class org.activemq.transport.remote.RemoteTransportChannel
 
getRemoveAllMessagesStatment() - Method in class org.activemq.store.jdbc.adapter.CachingStatementProvider
 
getRemoveAllMessagesStatment() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getRemoveAllMessagesStatment() - Method in interface org.activemq.store.jdbc.StatementProvider
 
getRemoveAllSubscriptionsStatment() - Method in class org.activemq.store.jdbc.adapter.CachingStatementProvider
 
getRemoveAllSubscriptionsStatment() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getRemoveAllSubscriptionsStatment() - Method in interface org.activemq.store.jdbc.StatementProvider
 
getRemoveMessageStatment() - Method in class org.activemq.store.jdbc.adapter.CachingStatementProvider
 
getRemoveMessageStatment() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getRemoveMessageStatment() - Method in interface org.activemq.store.jdbc.StatementProvider
 
getRemoveXidStatment() - Method in class org.activemq.store.jdbc.adapter.CachingStatementProvider
 
getRemoveXidStatment() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getRemoveXidStatment() - Method in interface org.activemq.store.jdbc.StatementProvider
 
getResource() - Method in exception org.activemq.spring.ConfigurationParseException
 
getResource() - Method in class org.activemq.spring.SpringBrokerContainerFactory
 
getResourceManagerId() - Method in class org.activemq.ActiveMQConnection
 
getResourceManagerId(BrokerClient) - Method in interface org.activemq.broker.BrokerConnector
Gets the unique id of the resource manager used for managing xa transactions.
getResourceManagerId(BrokerClient) - Method in class org.activemq.broker.impl.BrokerConnectorImpl
 
getResourceName() - Method in class org.activemq.message.CapacityInfo
 
getResult() - Method in class org.activemq.message.IntResponseReceipt
 
getResult() - Method in class org.activemq.message.ResponseReceipt
 
getResultBytes() - Method in class org.activemq.message.ResponseReceipt
 
getRight() - Method in class org.activemq.filter.AndFilter
 
getRight() - Method in class org.activemq.filter.BinaryExpression
 
getRight() - Method in class org.activemq.filter.OrFilter
 
getRight() - Method in class org.activemq.filter.UnaryExpression
 
getRoundedCapacity() - Method in class org.activemq.capacity.BasicCapacityMonitor
Calculates the capacity rounded down to the rounding factor
getRoundedCapacity() - Method in interface org.activemq.capacity.CapacityMonitor
Calculates the capacity rounded down to the rounding factor
getRoundedCapacity() - Method in class org.activemq.capacity.DelegateCapacityMonitor
Calculates the capacity rounded down to the rounding factor
getRoundingFactor() - Method in class org.activemq.capacity.BasicCapacityMonitor
Get the rounding factor - default is 10
getRoundingFactor() - Method in interface org.activemq.capacity.CapacityMonitor
Get the rounding factor - default is 10
getRoundingFactor() - Method in class org.activemq.capacity.DelegateCapacityMonitor
Get the rounding factor - default is 10
getSecurityAdapter() - Method in interface org.activemq.broker.Broker
Returns the security adapter used to authenticate and authorize access to JMS resources
getSecurityAdapter() - Method in interface org.activemq.broker.BrokerContainer
Returns the security adapter used to authenticate and authorize access to JMS resources
getSecurityAdapter() - Method in class org.activemq.broker.impl.BrokerContainerImpl
 
getSecurityAdapter() - Method in class org.activemq.broker.impl.DefaultBroker
 
getSecurityCredentials() - Method in class org.activemq.util.JndiJmsLogAppender
 
getSecurityPrincipalName() - Method in class org.activemq.util.JndiJmsLogAppender
 
getSeed() - Method in class org.activemq.util.IdGenerator
 
getSeedFromId(String) - Static method in class org.activemq.util.IdGenerator
From a generated id - return the seed (i.e.
getSelector() - Method in class org.activemq.message.ConsumerInfo
 
getSelector() - Method in class org.activemq.service.impl.SubscriptionImpl
 
getSelector() - Method in class org.activemq.service.SubscriberEntry
 
getSelector() - Method in interface org.activemq.service.Subscription
 
getSendCapacity() - Method in class org.activemq.transport.vm.VmTransportChannel
 
getSendChannel() - Method in class org.activemq.transport.vm.VmTransportChannel
 
getSendCloseTimeout() - Method in class org.activemq.ActiveMQConnection
 
getSendConnectionInfoTimeout() - Method in class org.activemq.ActiveMQConnection
 
getSendListener() - Method in class org.activemq.transport.vm.VmTransportChannel
 
getSendRoles() - Method in class org.activemq.security.jassjacc.DestinationSecurityConfig
 
getSequenceDataType() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getSequenceGenerator() - Method in class org.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
getSequenceGenerator() - Method in interface org.activemq.store.jdbc.JDBCAdapter
 
getSequenceNumber() - Method in class org.activemq.message.ActiveMQMessage
 
getSequenceNumber() - Method in class org.activemq.message.MessageAck
 
getSequenceNumber() - Method in class org.activemq.service.MessageIdentity
 
getServerChannel() - Method in interface org.activemq.broker.BrokerConnector
 
getServerChannel() - Method in class org.activemq.broker.impl.BrokerConnectorImpl
 
getServerSessionPool() - Method in class org.activemq.ActiveMQConnectionConsumer
Gets the server session pool associated with this connection consumer.
getServiceDetails() - Method in class org.activemq.transport.DiscoveryEvent
 
getServiceName() - Method in class org.activemq.transport.DiscoveryEvent
 
getServiceName() - Method in class org.activemq.transport.peer.PeerTransportChannel
 
getServicesCount() - Method in class org.activemq.transport.multicast.MulticastDiscoveryAgent
 
getSession() - Method in class org.activemq.ActiveMQXASession
 
getSession() - Method in class org.activemq.pool.PooledSession
 
getSession() - Method in class org.activemq.util.JmsLogAppenderSupport
 
getSessionCreatedBy() - Method in class org.activemq.message.ActiveMQDestination
 
getSessionId() - Method in class org.activemq.ActiveMQSession
 
getSessionId() - Method in class org.activemq.message.CleanupConnectionInfo
 
getSessionId() - Method in class org.activemq.message.ConsumerInfo
 
getSessionId() - Method in class org.activemq.message.MessageAck
 
getSessionId() - Method in class org.activemq.message.ProducerInfo
 
getSessionId() - Method in class org.activemq.message.SessionInfo
 
getSessionId() - Method in class org.activemq.transport.stomp.StompWireFormat
 
getSessionMode() - Method in class org.activemq.message.SessionInfo
 
getSessions() - Method in class org.activemq.management.JMSConnectionStatsImpl
 
getSessionStats() - Method in class org.activemq.ActiveMQSession
 
getSetDeadLetterFlagStatement() - Method in class org.activemq.store.jdbc.adapter.CachingStatementProvider
 
getSetDeadLetterFlagStatement() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getSetDeadLetterFlagStatement() - Method in interface org.activemq.store.jdbc.StatementProvider
 
getShort(String) - Method in class org.activemq.message.ActiveMQMapMessage
Returns the short value with the specified name.
getShortProperty(String) - Method in class org.activemq.message.ActiveMQMessage
Returns the value of the short property with the specified name.
getSocket() - Method in class org.activemq.transport.tcp.TcpTransportChannel
 
getSocketAddress() - Method in class org.activemq.transport.tcp.TcpTransportServerChannel
 
getSocketAddress() - Method in interface org.activemq.transport.TransportServerChannel
An optional method to return the socket address if there is one on which this channel is listening.
getSocketAddress() - Method in class org.activemq.transport.TransportServerChannelSupport
 
getSocketBufferSize() - Method in class org.activemq.transport.tcp.TcpTransportChannel
 
getSoTimeout() - Method in class org.activemq.transport.tcp.TcpTransportChannel
 
getStartTime() - Method in class org.activemq.ActiveMQMessageConsumer
 
getStartTime() - Method in class org.activemq.ActiveMQMessageProducer
 
getStartTime() - Method in class org.activemq.ActiveMQSession
 
getStartTime() - Method in class org.activemq.management.StatisticImpl
 
getStartTime() - Method in class org.activemq.message.BrokerInfo
 
getStartTime() - Method in class org.activemq.message.ConnectionInfo
 
getStartTime() - Method in class org.activemq.message.ConsumerInfo
 
getStartTime() - Method in class org.activemq.message.ProducerInfo
 
getStartTime() - Method in class org.activemq.message.SessionInfo
 
getState() - Method in class org.activemq.service.impl.AbstractTransaction
 
getStatementProvider() - Method in class org.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
getStatementProvider() - Method in interface org.activemq.store.jdbc.JDBCAdapter
 
getStatistic(String) - Method in class org.activemq.management.StatsImpl
 
getStatisticNames() - Method in class org.activemq.management.StatsImpl
 
getStatistics() - Method in class org.activemq.management.StatsImpl
 
getStats() - Method in class org.activemq.ActiveMQConnection
 
getStats() - Method in class org.activemq.ActiveMQConnectionFactory
 
getStats() - Method in class org.activemq.ActiveMQMessageConsumer
 
getStats() - Method in class org.activemq.ActiveMQMessageProducer
 
getStats() - Method in class org.activemq.ActiveMQSession
 
getStats() - Method in interface org.activemq.management.StatsCapable
 
getStats() - Method in class org.activemq.message.ActiveMQDestination
 
getStoreDirectory() - Method in class org.activemq.broker.impl.DefaultBroker
 
getString(String) - Method in class org.activemq.message.ActiveMQMapMessage
Returns the String value with the specified name.
getString(Map, String) - Static method in class org.activemq.util.MapHelper
Extracts the value from the map and coerces to a String
getStringIdDataType() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getStringProperty(String) - Method in class org.activemq.message.ActiveMQMessage
Returns the value of the String property with the specified name.
getSubject() - Method in interface org.activemq.broker.BrokerClient
 
getSubject() - Method in class org.activemq.broker.impl.BrokerClientImpl
 
getSubscriberEntry(ConsumerInfo) - Method in class org.activemq.store.cache.CacheTopicMessageStore
 
getSubscriberEntry(ConsumerInfo) - Method in class org.activemq.store.jdbc.JDBCTopicMessageStore
 
getSubscriberEntry(ConsumerInfo) - Method in class org.activemq.store.journal.JournalTopicMessageStore
 
getSubscriberEntry(ConsumerInfo) - Method in class org.activemq.store.ProxyTopicMessageStore
 
getSubscriberEntry(ConsumerInfo) - Method in interface org.activemq.store.TopicMessageStore
Finds the subscriber entry for the given consumer info
getSubscriberEntry(ConsumerInfo) - Method in class org.activemq.store.vm.VMTopicMessageStore
 
getSubscriberID() - Method in class org.activemq.service.SubscriberEntry
 
getSubscriberName() - Method in class org.activemq.message.DurableUnsubscribe
 
getSubscriberName() - Method in class org.activemq.service.impl.SubscriptionImpl
 
getSubscriberName() - Method in interface org.activemq.service.Subscription
 
getSubscription(String) - Method in class org.activemq.service.impl.SubscriptionContainerImpl
 
getSubscription(String) - Method in interface org.activemq.service.SubscriptionContainer
Gets the current subscription for the given consumerId if it is available
getSubscription() - Method in class org.activemq.store.journal.JournalAck
 
getSubscriptionEntry() - Method in class org.activemq.service.impl.SubscriptionImpl
 
getSubscriptionEntry() - Method in interface org.activemq.service.Subscription
Lazily creates the persistent entry representation of this subscription
getSubscriptionFor(ActiveMQDestination) - Method in class org.activemq.transport.stomp.StompWireFormat
 
getSubscriptionIdDataType() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getSubscriptions(ActiveMQDestination) - Method in class org.activemq.service.impl.SubscriptionContainerImpl
 
getSubscriptions(ActiveMQDestination) - Method in interface org.activemq.service.SubscriptionContainer
 
GetSuffix(int) - Method in class org.activemq.selector.SimpleCharStream
 
getSystemProperties() - Static method in class org.activemq.util.SystemProperties
 
getTable() - Method in class org.activemq.message.ActiveMQMapMessage
 
getTablePrefix() - Method in class org.activemq.store.jdbc.adapter.CachingStatementProvider
 
getTablePrefix() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getTablePrefix() - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
getTablePrefix() - Method in interface org.activemq.store.jdbc.StatementProvider
 
getTempDir() - Method in interface org.activemq.broker.Broker
Get a temp directory - used for spooling
getTempDir() - Method in class org.activemq.broker.impl.DefaultBroker
Get a temp directory - used for spooling
getText() - Method in class org.activemq.filter.PrefixDestinationFilter
 
getText() - Method in class org.activemq.filter.WildcardDestinationFilter
 
getText() - Method in class org.activemq.message.ActiveMQTextMessage
Gets the string containing this message's data.
getThreadPool() - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageManager
 
getThreadPool() - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageManager
 
getThreadPool() - Method in class org.activemq.transport.NetworkChannel
 
getThreadPool() - Method in class org.activemq.transport.NetworkConnector
 
getTimeoutCount() - Method in class org.activemq.transport.multicast.MulticastDiscoveryAgent
 
getTimeToLive() - Method in class org.activemq.ActiveMQMessageProducer
Gets the default length of time in milliseconds from its dispatch time that a produced message should be retained by the message system.
getTimeToLive() - Method in class org.activemq.pool.PooledProducer
 
getTimeToLive() - Method in class org.activemq.transport.multicast.MulticastDiscoveryAgent
 
getTimeToLive() - Method in class org.activemq.transport.multicast.MulticastTransportChannel
 
getToken(int) - Method in class org.activemq.selector.SelectorParser
 
getTopic() - Method in class org.activemq.ActiveMQTopicPublisher
Gets the topic associated with this TopicPublisher.
getTopic() - Method in class org.activemq.ActiveMQTopicSubscriber
Gets the Topic associated with this subscriber.
getTopic() - Method in class org.activemq.pool.PooledTopicPublisher
 
getTopicForConsumerAdvisory() - Method in class org.activemq.message.ActiveMQDestination
 
getTopicForProducerAdvisory() - Method in class org.activemq.message.ActiveMQDestination
 
getTopicForTempAdvisory() - Method in class org.activemq.message.ActiveMQDestination
 
getTopicName() - Method in class org.activemq.message.ActiveMQTopic
Gets the name of this Topic.
getTopicPrefetch() - Method in class org.activemq.ActiveMQPrefetchPolicy
 
getTopicPrefix() - Method in class org.activemq.jndi.ActiveMQInitialContextFactory
 
getTopicPublisher() - Method in class org.activemq.pool.PooledSession
 
getTopicPublisher() - Method in class org.activemq.pool.PooledTopicPublisher
 
getTopicSession() - Method in class org.activemq.ActiveMQXASession
 
getTotalMemoryUsedSize() - Method in class org.activemq.io.util.MemoryBoundedObjectManager
 
getTotalTime() - Method in class org.activemq.management.TimeStatisticImpl
 
getTransacted() - Method in class org.activemq.ActiveMQQueueSession
 
getTransacted() - Method in class org.activemq.ActiveMQSession
Indicates whether the session is in transacted mode.
getTransacted() - Method in class org.activemq.ActiveMQTopicSession
 
getTransacted() - Method in class org.activemq.ActiveMQXASession
 
getTransacted() - Method in class org.activemq.pool.PooledSession
 
getTransactionContext() - Method in class org.activemq.ActiveMQSession
 
getTransactionId() - Method in class org.activemq.message.ActiveMQMessage
 
getTransactionId() - Method in class org.activemq.message.MessageAck
 
getTransactionId() - Method in class org.activemq.message.TransactionInfo
 
getTransactionId() - Method in class org.activemq.service.impl.AutoCommitTransaction
 
getTransactionId() - Method in class org.activemq.service.impl.LocalTransactionCommand
 
getTransactionId() - Method in class org.activemq.service.impl.XATransactionCommand
 
getTransactionId() - Method in interface org.activemq.service.Transaction
 
getTransactionId() - Method in class org.activemq.store.journal.JournalAck
 
getTransactionId() - Method in class org.activemq.store.journal.TxCommand
 
getTransactionId() - Method in class org.activemq.TransactionContext
 
getTransactionId(String) - Method in class org.activemq.transport.stomp.StompWireFormat
 
getTransactionIDString() - Method in class org.activemq.message.ActiveMQMessage
A helper method for the OpenWire protocol
getTransactionIDString() - Method in class org.activemq.message.MessageAck
A helper method for the OpenWire protocol
getTransactionManager() - Method in class org.activemq.broker.impl.DefaultBroker
 
getTransactionStore() - Method in class org.activemq.store.journal.JournalPersistenceAdapter
 
getTransactionTimeout() - Method in class org.activemq.message.XATransactionInfo
 
getTransactionTimeout() - Method in class org.activemq.TransactionContext
 
getTransientQueueContainerManager() - Method in interface org.activemq.broker.Broker
 
getTransientQueueContainerManager() - Method in class org.activemq.broker.impl.DefaultBroker
 
getTransientTopicContainerManager() - Method in interface org.activemq.broker.Broker
 
getTransientTopicContainerManager() - Method in class org.activemq.broker.impl.DefaultBroker
 
getTransportChannel() - Method in class org.activemq.ActiveMQConnection
 
getTransportChannel() - Method in class org.activemq.transport.TransportStatusEvent
 
getTransportChannelListener() - Method in class org.activemq.transport.TransportChannelSupport
 
getTransportChannelListener() - Method in class org.activemq.transport.TransportServerChannelSupport
 
getTransportConnectors() - Method in interface org.activemq.broker.BrokerContainer
Returns the transport connectors used to communicate with clients
getTransportConnectors() - Method in class org.activemq.broker.impl.BrokerContainerImpl
 
getTransportDataIn() - Method in class org.activemq.io.AbstractWireFormat
 
getTransportDataOut() - Method in class org.activemq.io.AbstractWireFormat
 
getTTMPWireFormat() - Method in class org.activemq.transport.stomp.StompTransportChannel
 
getTx(Object, RecordLocation) - Method in class org.activemq.store.journal.JournalTransactionStore
 
getTx(Object) - Method in class org.activemq.store.vm.VMTransactionStore
 
getTxTableName() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getType() - Method in class org.activemq.message.TransactionInfo
 
getType() - Method in class org.activemq.message.XATransactionInfo
 
getType() - Method in class org.activemq.store.journal.TxCommand
 
getUnconsumedMessages() - Method in class org.activemq.ActiveMQSession
 
getUndeliveredMessages() - Method in class org.activemq.service.boundedvm.DurableQueueSubscription
 
getUndeliveredMessages() - Method in class org.activemq.service.boundedvm.TransientQueueSubscription
 
getUnit() - Method in class org.activemq.management.StatisticImpl
 
getUpdateDurableSubStatment() - Method in class org.activemq.store.jdbc.adapter.CachingStatementProvider
 
getUpdateDurableSubStatment() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getUpdateDurableSubStatment() - Method in interface org.activemq.store.jdbc.StatementProvider
 
getUpdateLastAckOfDurableSub() - Method in class org.activemq.store.jdbc.adapter.CachingStatementProvider
 
getUpdateLastAckOfDurableSub() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getUpdateLastAckOfDurableSub() - Method in interface org.activemq.store.jdbc.StatementProvider
 
getUpdateMessageStatment() - Method in class org.activemq.store.jdbc.adapter.CachingStatementProvider
 
getUpdateMessageStatment() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getUpdateMessageStatment() - Method in interface org.activemq.store.jdbc.StatementProvider
 
getUpperBound() - Method in class org.activemq.management.BoundaryStatisticImpl
 
getUpperBound() - Method in class org.activemq.management.BoundedRangeStatisticImpl
 
getUri() - Method in class org.activemq.transport.multicast.MulticastDiscoveryAgent
 
getUri() - Method in class org.activemq.transport.multicast.MulticastTester
 
getUri() - Method in class org.activemq.transport.NetworkChannel
 
getUri() - Method in class org.activemq.util.JmsLogAppender
 
getUris() - Method in class org.activemq.transport.composite.CompositeTransportChannel
 
getUrl() - Method in interface org.activemq.transport.TransportServerChannel
Returns the URL to connect to this connector
getUrl() - Method in class org.activemq.transport.TransportServerChannelSupport
 
getUrlPkgPrefixes() - Method in class org.activemq.util.JndiJmsLogAppender
 
getUserName() - Method in class org.activemq.ActiveMQConnectionFactory
 
getUserName() - Method in class org.activemq.message.ConnectionInfo
 
getUserName() - Method in class org.activemq.pool.ConnectionKey
 
getUserName() - Method in class org.activemq.util.JmsLogAppender
 
getUserName() - Method in class org.activemq.util.JndiJmsLogAppender
 
getUserName() - Static method in class org.activemq.util.SystemProperties
 
getUseTime() - Method in class org.activemq.management.JCAConnectionStatsImpl
 
getValidSetOfActions() - Method in class org.activemq.security.jassjacc.AbstractJMSPermission
 
getValidSetOfActions() - Method in class org.activemq.security.jassjacc.JMSBrokerPermission
 
getValidSetOfActions() - Method in class org.activemq.security.jassjacc.JMSDestinationPermission
 
getValue() - Method in class org.activemq.filter.ConstantExpression
 
getValue() - Method in class org.activemq.message.CachedValue
 
getValueFromReadCache(short) - Method in class org.activemq.io.impl.AbstractDefaultWireFormat
 
getValueFromReadCache(short) - Method in class org.activemq.io.impl.DefaultWireFormat
 
getValueFromReadCache(short) - Method in class org.activemq.io.impl.StatelessDefaultWireFormat
 
getValueLimit() - Method in class org.activemq.capacity.BasicCapacityMonitor
 
getValueLimit() - Method in interface org.activemq.capacity.CapacityMonitor
 
getValueLimit() - Method in class org.activemq.capacity.DelegateCapacityMonitor
 
getValues() - Method in class org.activemq.filter.DestinationMapNode
Returns a mutable List of the values available at this node in the tree
getVersion() - Method in class org.activemq.message.WireFormatInfo
 
getWaitingThreadCount() - Method in class org.activemq.management.JCAConnectionPoolStatsImpl
 
getWaitTime() - Method in class org.activemq.management.JCAConnectionStatsImpl
 
getWasPrepared() - Method in class org.activemq.store.journal.TxCommand
 
getWireFormat() - Method in class org.activemq.ActiveMQConnectionFactory
 
getWireFormat(DataInputStream) - Method in class org.activemq.io.WireFormatLoader
Create a wire format
getWireFormat(String) - Static method in class org.activemq.io.WireFormatLoader
load a WireFormat by name - e.g.
getWireFormat() - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
getWireFormat() - Method in class org.activemq.store.journal.JournalPersistenceAdapter
 
getWireFormat() - Method in class org.activemq.transport.peer.PeerTransportChannel
 
getWireFormat() - Method in class org.activemq.transport.remote.RemoteTransportChannel
 
getWireFormat() - Method in class org.activemq.transport.tcp.TcpTransportServerChannel
 
getWireFormat() - Method in interface org.activemq.transport.TransportChannel
Get the current wireformat used by this channel
getWireFormat() - Method in class org.activemq.transport.TransportChannelSupport
Get the current wireformat used by this channel
getWireFormatVersion() - Method in class org.activemq.io.impl.AbstractPacketMarshaller
 
getWireFormatVersion() - Method in class org.activemq.io.impl.AbstractPacketReader
 
getWireFormatVersion() - Method in class org.activemq.io.impl.AbstractPacketWriter
 
getWireFormatVersion() - Method in interface org.activemq.io.impl.PacketReader
 
getWireFormatVersion() - Method in interface org.activemq.io.impl.PacketWriter
 
getWireFormatVersion() - Method in class org.activemq.message.ConnectionInfo
 
getWriteCachedKey(Object) - Method in class org.activemq.io.impl.DefaultWireFormat
 
getWriter(Packet) - Method in class org.activemq.io.impl.AbstractDefaultWireFormat
 
getWriter() - Method in class org.activemq.transport.jabber.JabberWireFormat
 
getXAResource() - Method in class org.activemq.ActiveMQXASession
 
getXATransaction(ActiveMQXid) - Method in class org.activemq.service.impl.TransactionManagerImpl
 
getXATransaction(ActiveMQXid) - Method in class org.activemq.service.TransactionManager
 
getXid() - Method in class org.activemq.message.XATransactionInfo
 
getXidDataType() - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getXmppType(ActiveMQMessage) - Method in class org.activemq.transport.jabber.JabberWireFormat
 
getXslResource() - Method in class org.activemq.spring.ActiveMQBeanDefinitionReader
 

H

handle(Callback[]) - Method in class org.activemq.security.jassjacc.UsernamePasswordCallback
 
handleAsyncException(JMSException) - Method in class org.activemq.ActiveMQConnection
Used for handling async exceptions
handleCachedValue(CachedValue) - Method in class org.activemq.io.impl.AbstractDefaultWireFormat
 
handleCachedValue(CachedValue) - Method in class org.activemq.io.impl.DefaultWireFormat
 
handleCachedValue(CachedValue) - Method in class org.activemq.io.impl.StatelessDefaultWireFormat
 
handleIdGenerator - Variable in class org.activemq.ActiveMQConnection
 
hasAckedMessage() - Method in class org.activemq.service.boundedvm.DurableQueueSubscription
 
hasAckedMessage() - Method in class org.activemq.service.boundedvm.TransientQueueSubscription
Add an acked message.
hasConsumerFor(ActiveMQDestination) - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
 
hasConsumerFor(ActiveMQDestination) - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageManager
 
hash(byte[], int) - Method in class org.activemq.message.ActiveMQXid
 
hashCode() - Method in class org.activemq.ActiveMQQueueSession
 
hashCode() - Method in class org.activemq.ActiveMQTopicSession
 
hashCode() - Method in class org.activemq.advisories.TempDestinationAdvisoryEvent
 
hashCode() - Method in class org.activemq.filter.BinaryExpression
TODO: more efficient hashCode()
hashCode() - Method in class org.activemq.filter.ConstantExpression
TODO: more efficient hashCode()
hashCode() - Method in class org.activemq.filter.MultiExpressionEvaluator.CacheExpression
 
hashCode() - Method in class org.activemq.filter.PropertyExpression
 
hashCode() - Method in class org.activemq.filter.UnaryExpression
TODO: more efficient hashCode()
hashCode() - Method in class org.activemq.message.AbstractPacket
 
hashCode() - Method in class org.activemq.message.ActiveMQDestination
 
hashCode() - Method in class org.activemq.message.ActiveMQMessage
 
hashCode() - Method in class org.activemq.message.ActiveMQXid
 
hashCode() - Method in class org.activemq.message.BrokerAdminCommand
 
hashCode() - Method in class org.activemq.message.CleanupConnectionInfo
 
hashCode() - Method in class org.activemq.message.ConnectionInfo
 
hashCode() - Method in class org.activemq.message.ConsumerInfo
 
hashCode() - Method in class org.activemq.message.ProducerInfo
 
hashCode() - Method in class org.activemq.message.SessionInfo
 
hashCode() - Method in class org.activemq.message.TransactionInfo
 
hashCode() - Method in class org.activemq.message.XATransactionInfo
 
hashCode() - Method in class org.activemq.pool.ConnectionKey
 
hashCode() - Method in class org.activemq.pool.SessionKey
 
hashCode() - Method in class org.activemq.security.jassjacc.AbstractJMSPermission
 
hashCode() - Method in class org.activemq.service.impl.MessageEntry
 
hashCode() - Method in class org.activemq.service.MessageIdentity
 
hasMoreElements() - Method in class org.activemq.ActiveMQQueueBrowser
 
hasNext() - Method in class org.activemq.util.URIHelper
 
hasReceivedMessage() - Method in class org.activemq.spring.TestingConsumer
 
hasReceivedMessages(int) - Method in class org.activemq.spring.TestingConsumer
 
hasUncomsumedMessages() - Method in class org.activemq.ActiveMQSession
 
hasVisited(String) - Method in class org.activemq.message.AbstractPacket
test to see if the named broker has already seen this packet
hasVisited(String) - Method in interface org.activemq.message.Packet
test to see if the named broker has already seen this packet
HEAD_KEY - Static variable in class org.activemq.service.impl.QueueListSupport
 
headKey - Variable in class org.activemq.service.impl.QueueListSupport.Header
 
HEX_LITERAL - Static variable in interface org.activemq.selector.SelectorParserConstants
 
HOWL_JOURNAL_TYPE - Static variable in class org.activemq.store.journal.JournalPersistenceAdapter
 
HsqldbJDBCAdapter - Class in org.activemq.store.jdbc.adapter
 
HsqldbJDBCAdapter() - Constructor for class org.activemq.store.jdbc.adapter.HsqldbJDBCAdapter
 
HsqldbJDBCAdapter(StatementProvider) - Constructor for class org.activemq.store.jdbc.adapter.HsqldbJDBCAdapter
 
HsqldbJDBCAdapter.HSQLStatementProvider - Class in org.activemq.store.jdbc.adapter
 
HsqldbJDBCAdapter.HSQLStatementProvider() - Constructor for class org.activemq.store.jdbc.adapter.HsqldbJDBCAdapter.HSQLStatementProvider
 

I

ID - Static variable in interface org.activemq.selector.SelectorParserConstants
 
ID - Static variable in interface org.activemq.transport.stomp.Stomp.Headers.Subscribe
 
IdGenerator - Class in org.activemq.util
Generator for globally unique Strings
IdGenerator() - Constructor for class org.activemq.util.IdGenerator
Construct an IdGenerator
IdGenerator(String) - Constructor for class org.activemq.util.IdGenerator
Construct an IdGenerator using the seed provided
image - Variable in class org.activemq.selector.Token
The string image of the token.
ImageBasedJDBCAdaptor - Class in org.activemq.store.jdbc.adapter
Provides JDBCAdapter since that uses IMAGE datatype to hold binary data.
ImageBasedJDBCAdaptor() - Constructor for class org.activemq.store.jdbc.adapter.ImageBasedJDBCAdaptor
 
ImageBasedJDBCAdaptor(StatementProvider) - Constructor for class org.activemq.store.jdbc.adapter.ImageBasedJDBCAdaptor
 
implies(Permission) - Method in class org.activemq.security.jassjacc.AbstractJMSPermission
 
IN - Static variable in interface org.activemq.selector.SelectorParserConstants
 
IN_USE_STATE - Static variable in class org.activemq.service.impl.AbstractTransaction
 
increment() - Method in class org.activemq.management.CountStatisticImpl
 
incrementConsumerCounter() - Method in class org.activemq.message.ActiveMQDestination
increment counter for number of interested consumers
incrementDeliveryCount() - Method in class org.activemq.message.ActiveMQMessage
Increment the delivery count
incrementDeliveryCount() - Method in class org.activemq.service.boundedvm.DurableMessagePointer
 
incrementIndent() - Method in class org.activemq.util.IndentPrinter
 
incrementMemoryReferenceCount() - Method in interface org.activemq.io.util.MemoryManageable
Increment reference count for bounded memory collections
incrementMemoryReferenceCount() - Method in class org.activemq.message.AbstractPacket
Increment reference count for bounded memory collections
incrementMemoryReferenceCount() - Method in interface org.activemq.message.Packet
Increment reference count for bounded memory collections
incrementMemoryReferenceCount() - Method in class org.activemq.service.boundedvm.DurableMessagePointer
 
incrementMemoryUsed(int) - Method in class org.activemq.io.util.MemoryBoundedObjectManager
 
incrementMemoryUsed(MemoryManageable) - Method in class org.activemq.io.util.MemoryBoundedQueue
 
incrementMemoryUsed(int) - Method in class org.activemq.io.util.MemoryBoundedQueueManager
 
incrementMessageCount(MessageIdentity) - Method in class org.activemq.store.cache.CacheTopicMessageStore
 
incrementMessageCount(MessageIdentity) - Method in class org.activemq.store.jdbc.JDBCTopicMessageStore
 
incrementMessageCount(MessageIdentity) - Method in class org.activemq.store.journal.JournalTopicMessageStore
 
incrementMessageCount(MessageIdentity) - Method in class org.activemq.store.ProxyTopicMessageStore
 
incrementMessageCount(MessageIdentity) - Method in interface org.activemq.store.TopicMessageStore
Increments the reference count of the message ID as its been dispatched to another subscriber.
incrementMessageCount(MessageIdentity) - Method in class org.activemq.store.vm.VMTopicMessageStore
 
incrementRedeliveryCount() - Method in class org.activemq.message.ActiveMQMessage
Increment the redelivery count, which is the same as the delivery count except it does not consider the initial delivery upon message creation
incrementRedeliveryCount() - Method in class org.activemq.service.boundedvm.DurableMessagePointer
 
incrementTimeout - Variable in class org.activemq.transport.composite.CompositeTransportChannel
 
IndentPrinter - Class in org.activemq.util
A helper class for printing indented text
IndentPrinter() - Constructor for class org.activemq.util.IndentPrinter
 
IndentPrinter(PrintWriter) - Constructor for class org.activemq.util.IndentPrinter
 
IndentPrinter(PrintWriter, String) - Constructor for class org.activemq.util.IndentPrinter
 
indexOf(Object) - Method in class org.activemq.service.impl.DefaultQueueList
 
indexOf(Object) - Method in class org.activemq.service.impl.QueueListSupport
 
indexOf(Object) - Method in interface org.activemq.service.QueueList
Returns the index in this list of the first occurrence of the specified element, or -1 if the List does not contain this element.
inetAddress - Variable in class org.activemq.transport.udp.UdpTransportChannel
 
inflate(ByteArray) - Method in class org.activemq.io.util.ByteArrayCompression
Inflate a ByteArray (if it contains compressed data)
inFlightTxLocations - Variable in class org.activemq.store.journal.JournalMessageStore
 
InformixJDBCAdapter - Class in org.activemq.store.jdbc.adapter
JDBC Adapter for Informix database.
InformixJDBCAdapter() - Constructor for class org.activemq.store.jdbc.adapter.InformixJDBCAdapter
 
InformixJDBCAdapter(StatementProvider) - Constructor for class org.activemq.store.jdbc.adapter.InformixJDBCAdapter
 
InitialImageMessageContainerManager - Class in org.activemq.service.impl
Implements an initial image service where on subscription the client will receive the last image that was previously cached.
InitialImageMessageContainerManager(MessageContainerManager, Map, DestinationFilter) - Constructor for class org.activemq.service.impl.InitialImageMessageContainerManager
Creates a topic based initial image message container manager using the given destination filter
InitialImageMessageContainerManager(MessageContainerManager, Map, boolean, DestinationFilter) - Constructor for class org.activemq.service.impl.InitialImageMessageContainerManager
 
initialise(Map, TransactionStore) - Method in class org.activemq.service.impl.XATransactionCommand
Called after the transaction command has been recovered from disk
initialiseSocket(Socket) - Method in class org.activemq.transport.tcp.TcpTransportChannel
Configures the socket for use
initialize(BrokerConnector, TransportChannel) - Method in interface org.activemq.broker.BrokerClient
Initialize the Brokerclient
initialize(BrokerConnector, TransportChannel) - Method in class org.activemq.broker.impl.BrokerClientImpl
Initialize the BrokerClient
initialize() - Method in class org.activemq.transport.jabber.JabberWireFormat
 
initialize() - Method in class org.activemq.transport.NetworkChannel
 
initialize() - Method in class org.activemq.transport.RemoteNetworkChannel
remote:// can only make outgoing connections - we assume we can't accept incomming (duck!).
initializeOther(AbstractPacket) - Method in class org.activemq.message.AbstractPacket
Initializes another message with current values from this instance
initializeOther(ActiveMQMessage) - Method in class org.activemq.message.ActiveMQMessage
Initializes another message with current values from this instance
initializeStreams() - Method in class org.activemq.transport.jabber.JabberTransportChannel
 
initializeStreams() - Method in class org.activemq.transport.tcp.TcpTransportChannel
 
initiateClientSideProtocol() - Method in class org.activemq.io.AbstractWireFormat
Some wire formats require a handshake at start-up
initiateClientSideProtocol(DataOutputStream, DataInputStream) - Method in class org.activemq.io.impl.AbstractDefaultWireFormat
Some wire formats require a handshake at start-up
initiateClientSideProtocol() - Method in interface org.activemq.io.WireFormat
Some wire formats require a handshake at start-up
initiateClientSideProtocol() - Method in class org.activemq.transport.stomp.StompWireFormat
Some wire formats require a handshake at start-up
initiateServerSideProtocol() - Method in class org.activemq.io.AbstractWireFormat
Some wire formats require a handshake at start-up
initiateServerSideProtocol(DataOutputStream, DataInputStream) - Method in class org.activemq.io.impl.AbstractDefaultWireFormat
Some wire formats require a handshake at start-up
initiateServerSideProtocol() - Method in interface org.activemq.io.WireFormat
Some wire formats require a handshake at start-up
initiateServerSideProtocol() - Method in class org.activemq.transport.stomp.StompWireFormat
Some wire formats require a handshake at start-up
initSequenceGenerator(Connection) - Method in class org.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
initSequenceGenerator(Connection) - Method in interface org.activemq.store.jdbc.JDBCAdapter
 
inLock - Variable in class org.activemq.io.util.MemoryBoundedQueue
 
inspect(Destination) - Static method in class org.activemq.message.ActiveMQDestination
A helper method to return a descriptive string for the topic or queue
installSecurity() - Method in class org.activemq.security.jassjacc.PropertiesConfigLoader
 
INT_RESPONSE_RECEIPT_INFO - Static variable in interface org.activemq.message.Packet
A receipt with an Integer reponse.
INTEGER - Static variable in class org.activemq.filter.ArithmeticExpression
 
internalBind(String, Object) - Method in class org.activemq.jndi.ReadOnlyContext
internalBind is intended for use only during setup or possibly by suitably synchronized superclasses.
internalBytesIn - Variable in class org.activemq.io.impl.DefaultWireFormat
 
internalBytesOut - Variable in class org.activemq.io.impl.DefaultWireFormat
 
internalConnection - Variable in class org.activemq.ActiveMQConnectionFactory
 
internalDataIn - Variable in class org.activemq.io.impl.DefaultWireFormat
 
internalDataOut - Variable in class org.activemq.io.impl.DefaultWireFormat
 
intReponseReceiptReader - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
intReponseReceiptWriter - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
IntResponseReceipt - Class in org.activemq.message
A receipt that also carries a reponse object.
IntResponseReceipt() - Constructor for class org.activemq.message.IntResponseReceipt
 
IntResponseReceiptReader - Class in org.activemq.io.impl
Reads a ConsumerInfo object from a Stream
IntResponseReceiptReader() - Constructor for class org.activemq.io.impl.IntResponseReceiptReader
 
IntResponseReceiptWriter - Class in org.activemq.io.impl
Writes a ConsumerInfo object to a Stream
IntResponseReceiptWriter() - Constructor for class org.activemq.io.impl.IntResponseReceiptWriter
 
invoke(Object, Method, Object[]) - Method in class org.activemq.util.AsyncProxy
 
IS - Static variable in interface org.activemq.selector.SelectorParserConstants
 
isActive(String) - Method in class org.activemq.advisories.ConnectionAdvisor
returns true if the connection is active
isActive(Destination) - Method in class org.activemq.advisories.ConsumerAdvisor
returns true if there is an active subscriber for the destination
isActive(Destination) - Method in class org.activemq.advisories.ProducerAdvisor
returns true if there is an active producer for the destination
isActive(Destination) - Method in class org.activemq.advisories.TempDestinationAdvisor
returns true if the temporary destination is active
isActive() - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageContainer
 
isActive() - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
 
isActive() - Method in class org.activemq.service.impl.SubscriptionImpl
 
isActive() - Method in interface org.activemq.service.Subscription
 
isAdvisory() - Method in class org.activemq.message.ActiveMQDestination
 
isAdvisory() - Method in class org.activemq.message.ActiveMQMessage
 
isAdvisory() - Method in class org.activemq.message.ConsumerInfo
 
isAllowDuplicates() - Method in class org.activemq.service.DeadLetterPolicy
 
isAsyncSend() - Method in class org.activemq.transport.vm.VmTransportChannel
 
isAtPrefetchLimit() - Method in class org.activemq.service.impl.SubscriptionImpl
Indicates the Subscription it's reached it's pre-fetch limit
isAtPrefetchLimit() - Method in interface org.activemq.service.Subscription
Indicates the Subscription it's reached it's pre-fetch limit
isAuthorizedForMessage(ActiveMQMessage) - Method in class org.activemq.service.impl.SubscriptionImpl
Returns whether or not the consumer can receive the given message
isAutoCleanupExpiredMessages() - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
isBackOffMode() - Method in class org.activemq.service.RedeliveryPolicy
Returns whether or not we use a back-off timeout (increasing the timeout by the RedeliveryPolicy.getBackOffIncreaseRate() each time).
isBodyConvertedToBytes() - Method in class org.activemq.message.ActiveMQMessage
 
isBrokerConnection() - Method in interface org.activemq.broker.BrokerClient
 
isBrokerConnection() - Method in class org.activemq.broker.impl.BrokerClientImpl
 
isBrowser() - Method in class org.activemq.ActiveMQMessageConsumer
Retrive is a browser
isBrowser() - Method in class org.activemq.message.ConsumerInfo
 
isBrowser() - Method in class org.activemq.service.boundedvm.DurableQueueSubscription
 
isBrowser() - Method in class org.activemq.service.boundedvm.TransientQueueSubscription
 
isBrowser() - Method in class org.activemq.service.impl.SubscriptionImpl
Indicates the consumer is a browser only
isBrowser() - Method in interface org.activemq.service.Subscription
Indicates the consumer is a browser only
isCachingEnabled() - Method in class org.activemq.ActiveMQConnection
 
isCachingEnabled() - Method in class org.activemq.ActiveMQConnectionFactory
 
isCachingEnabled() - Method in class org.activemq.io.AbstractWireFormat
 
isCachingEnabled() - Method in class org.activemq.io.impl.StatelessDefaultWireFormat
 
isCachingEnabled() - Method in interface org.activemq.io.WireFormat
 
isCachingEnabled() - Method in class org.activemq.transport.stomp.StompWireFormat
 
isCachingEnabled() - Method in interface org.activemq.transport.TransportChannel
 
isCachingEnabled() - Method in class org.activemq.transport.TransportChannelSupport
 
isClientAcknowledge() - Method in class org.activemq.ActiveMQSession
 
isClosed() - Method in class org.activemq.message.ConnectionInfo
 
isClosed() - Method in class org.activemq.transport.tcp.TcpTransportChannel
 
isClusteredConnection() - Method in interface org.activemq.broker.BrokerClient
 
isClusteredConnection() - Method in class org.activemq.broker.impl.BrokerClientImpl
 
isComposite() - Method in class org.activemq.message.ActiveMQDestination
Returns true if this destination represents a collection of destinations; allowing a set of destinations to be published to or subscribed from in one JMS operation.
isCompressed(ByteArray) - Static method in class org.activemq.io.util.ByteArrayCompression
test for compressed data
isConnectionAdvisory() - Method in class org.activemq.message.ActiveMQDestination
 
isConsumerActiveOnDestination(ActiveMQDestination) - Method in class org.activemq.service.impl.DurableTopicMessageContainerManager
 
isConsumerAdvisory() - Method in class org.activemq.message.ActiveMQDestination
 
isConsumerTarget(int) - Method in class org.activemq.message.ActiveMQMessage
test to see if a particular Consumer at a Connection is meant to receive this Message
isCopyMessageOnSend() - Method in class org.activemq.ActiveMQConnection
 
isCopyMessageOnSend() - Method in class org.activemq.ActiveMQConnectionFactory
 
isCurrentTransaction() - Static method in class org.activemq.service.TransactionManager
 
isDeadLetterEnabled() - Method in class org.activemq.service.DeadLetterPolicy
 
isDeadLetterPerDestinationName() - Method in class org.activemq.service.DeadLetterPolicy
 
isDeadLetterQueue() - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
 
isDeadLetterQueue() - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
 
isDeadLetterQueue() - Method in class org.activemq.service.impl.DurableQueueMessageContainer
 
isDeadLetterQueue() - Method in class org.activemq.service.impl.DurableTopicMessageContainer
 
isDeadLetterQueue() - Method in interface org.activemq.service.MessageContainer
returns true if this container is a dead letter queue
isDecoupledDispatch() - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageManager
 
isDeleted() - Method in class org.activemq.message.ActiveMQDestination
 
isDemandBasedForwarding() - Method in class org.activemq.transport.NetworkChannel
 
isDisableTimeStampsByDefault() - Method in class org.activemq.ActiveMQConnection
 
isDisableTimeStampsByDefault() - Method in class org.activemq.ActiveMQConnectionFactory
 
isDispatchedFromDLQ() - Method in class org.activemq.message.ActiveMQMessage
 
isDoDiscovery() - Method in class org.activemq.transport.peer.PeerTransportChannel
 
isDoMessageCompression() - Method in class org.activemq.ActiveMQConnection
 
isDoMessageCompression() - Method in class org.activemq.ActiveMQConnectionFactory
 
isDoMessageFragmentation() - Method in class org.activemq.ActiveMQConnection
 
isDoMessageFragmentation() - Method in class org.activemq.ActiveMQConnectionFactory
 
isDuplicate(Message) - Method in class org.activemq.ActiveMQMessageAudit
Checks if this message has beeb seen before
isDuplicate(String) - Method in class org.activemq.ActiveMQMessageAudit
checks whether this messageId has been seen before and adds this messageId to the list
isDurableSubscriber() - Method in class org.activemq.ActiveMQMessageConsumer
 
isDurableTopic() - Method in class org.activemq.message.ConsumerInfo
 
isDurableTopic() - Method in class org.activemq.service.boundedvm.TransientTopicSubscription
 
isDurableTopic() - Method in class org.activemq.service.impl.SubscriptionImpl
Indicates the Subscriber is a Durable Subscriber
isDurableTopic() - Method in interface org.activemq.service.Subscription
Indicates the Consumer is a Durable Subscriber
isEmpty() - Method in class org.activemq.io.util.MemoryBoundedPrioritizedQueue
 
isEmpty() - Method in class org.activemq.io.util.MemoryBoundedQueue
 
isEmpty() - Method in class org.activemq.io.util.SpooledBoundedActiveMQMessageQueue
 
isEmpty() - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageContainer
 
isEmpty() - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
 
isEmpty() - Method in class org.activemq.service.impl.DefaultQueueList
 
isEmpty() - Method in class org.activemq.service.impl.QueueListSupport
 
isEmpty() - Method in interface org.activemq.service.QueueList
is the list empty?
isEntryBroker(String) - Method in class org.activemq.message.ActiveMQMessage
Determine if the message originated in the network from the named broker
isEntryCluster(String) - Method in class org.activemq.message.ActiveMQMessage
Determine if the message originated in the network from the named cluster
isEqual(Object, Object) - Static method in class org.activemq.pool.ConnectionKey
 
isExclusive() - Method in class org.activemq.message.ActiveMQDestination
 
isExpired(long) - Method in class org.activemq.message.ActiveMQMessage
Indicates if the Message has expired
isExpired() - Method in class org.activemq.message.ActiveMQMessage
 
isExpired() - Method in class org.activemq.message.MessageAck
 
isExternalMessageId() - Method in class org.activemq.message.ActiveMQMessage
 
isExternalMessageId() - Method in class org.activemq.message.MessageAck
 
isFailed() - Method in class org.activemq.message.Receipt
 
isFull() - Method in class org.activemq.io.util.MemoryBoundedObjectManager
 
isFull() - Method in class org.activemq.io.util.MemoryBoundedQueueManager
 
isFull() - Method in class org.activemq.io.util.SpooledBoundedActiveMQMessageQueue
 
isInactive() - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
 
isIncrementTimeout() - Method in class org.activemq.transport.composite.CompositeTransportChannel
 
isInDemand() - Method in class org.activemq.advisories.ProducerDemandAdvisor
 
isInDemand() - Method in class org.activemq.advisories.ProducerDemandEvent
 
isInLocalTransaction() - Method in class org.activemq.TransactionContext
 
isInternalConnection() - Method in class org.activemq.ActiveMQConnection
 
isInternalConnection() - Method in class org.activemq.ActiveMQConnectionFactory
 
isInternalSession() - Method in class org.activemq.ActiveMQSession
 
isInXATransaction() - Method in class org.activemq.TransactionContext
 
isJ2EEcompliant() - Method in class org.activemq.ActiveMQConnection
 
isJ2EEcompliant() - Method in class org.activemq.ActiveMQConnectionFactory
 
isJMSMessage() - Method in class org.activemq.message.AbstractPacket
Retrieve if a JMS Message type or not
isJMSMessage() - Method in class org.activemq.message.ActiveMQMessage
Retrieve if a JMS Message type or not
isJMSMessage() - Method in interface org.activemq.message.Packet
Retrieve if a JMS Message type or not
isLastMessagePart() - Method in class org.activemq.message.ActiveMQMessage
 
isLocalSubscription() - Method in class org.activemq.service.boundedvm.DurableSubscription
 
isLocalSubscription() - Method in class org.activemq.service.boundedvm.TransientSubscription
 
isLocalSubscription() - Method in class org.activemq.service.impl.SubscriptionImpl
 
isLocalSubscription() - Method in interface org.activemq.service.Subscription
 
isMaintainDestinationStats() - Method in class org.activemq.service.impl.MessageContainerManagerSupport
 
isMemoryLimitEnforced() - Method in class org.activemq.io.util.MemoryBoundedQueueManager
 
isMessageConsumed() - Method in class org.activemq.message.ActiveMQMessage
 
isMessagePart() - Method in class org.activemq.message.ActiveMQMessage
 
isMessageRead() - Method in class org.activemq.message.MessageAck
 
isMulticast() - Method in class org.activemq.transport.composite.CompositeTransportChannel
 
isMulticast() - Method in class org.activemq.transport.multicast.MulticastTransportChannel
 
isMulticast() - Method in class org.activemq.transport.tcp.TcpTransportChannel
 
isMulticast() - Method in interface org.activemq.transport.TransportChannel
 
isMulticast() - Method in class org.activemq.transport.TransportChannelSupport
 
isMulticast() - Method in class org.activemq.transport.udp.UdpTransportChannel
 
isMulticast() - Method in class org.activemq.transport.vm.VmTransportChannel
 
isNoDelay() - Method in interface org.activemq.transport.TransportChannel
Inform Transport to send messages as quickly as possible - for Tcp - this means disabling Nagles, which on OSX may provide better performance for sync sends
isNoDelay() - Method in class org.activemq.transport.TransportChannelSupport
Inform Transport to send messages as quickly as possible - for Tcp - this means disabling Nagles, which on OSX may provide better performance for sync sends
isNoLocal() - Method in class org.activemq.ActiveMQMessageConsumer
 
isNoLocal() - Method in class org.activemq.message.ConsumerInfo
 
isNoLocal() - Method in class org.activemq.service.impl.SubscriptionImpl
 
isNoTopicConsumerEnabled() - Method in class org.activemq.service.DeadLetterPolicy
 
isOptimizedMessageDispatch() - Method in class org.activemq.ActiveMQConnection
 
isOptimizedMessageDispatch() - Method in class org.activemq.ActiveMQConnectionFactory
 
isOrdered() - Method in class org.activemq.message.ActiveMQDestination
 
isPartOfTransaction() - Method in class org.activemq.message.ActiveMQMessage
 
isPartOfTransaction() - Method in class org.activemq.message.MessageAck
 
isPendingStop() - Method in interface org.activemq.transport.TransportChannel
 
isPendingStop() - Method in class org.activemq.transport.TransportChannelSupport
 
isPersistent() - Method in class org.activemq.message.ActiveMQMessage
 
isPersistent() - Method in class org.activemq.message.MessageAck
 
isPersistent() - Method in class org.activemq.transport.peer.PeerTransportChannel
 
isPrepareMessageBodyOnSend() - Method in class org.activemq.ActiveMQConnection
Causes pre-serialization of messages before send By default this is on
isPrepareMessageBodyOnSend() - Method in class org.activemq.ActiveMQConnectionFactory
Causes pre-serialization of messages before send By default this is on
isProducerAdvisory() - Method in class org.activemq.message.ActiveMQDestination
 
isQueue() - Method in class org.activemq.message.ActiveMQDestination
Returns true if a Queue Destination
isQueue() - Method in class org.activemq.message.ActiveMQQueue
Returns true if a Queue Destination
isQueue() - Method in class org.activemq.message.ActiveMQTemporaryQueue
Returns true if a Queue Destination
isQuickClose() - Method in class org.activemq.ActiveMQConnection
 
isQuickClose() - Method in class org.activemq.ActiveMQConnectionFactory
 
isReadyToDispatch() - Method in class org.activemq.service.impl.SubscriptionImpl
Indicates if this Subscription has more messages to send to the Consumer
isReadyToDispatch() - Method in interface org.activemq.service.Subscription
Indicates if this Subscription has more messages to send to the Consumer
isReceipt() - Method in class org.activemq.message.AbstractPacket
 
isReceipt() - Method in interface org.activemq.message.Packet
 
isReceipt() - Method in class org.activemq.message.Receipt
 
isReceiptRequired() - Method in class org.activemq.message.AbstractPacket
 
isReceiptRequired() - Method in interface org.activemq.message.Packet
 
isRemote() - Method in class org.activemq.message.BrokerInfo
 
isRemote() - Method in class org.activemq.transport.peer.PeerTransportChannel
 
isResuseMessageId() - Method in class org.activemq.ActiveMQMessageProducer
 
isSameDurableSubscription(ConsumerInfo) - Method in class org.activemq.service.impl.SubscriptionImpl
 
isSameDurableSubscription(ConsumerInfo) - Method in interface org.activemq.service.Subscription
Checks if this subscription is a duplicate durable subscription of the given consumer info
isSameRM(XAResource) - Method in class org.activemq.TransactionContext
 
isServerSide() - Method in interface org.activemq.transport.TransportChannel
 
isServerSide() - Method in class org.activemq.transport.TransportChannelSupport
 
isSingleton() - Method in class org.activemq.spring.BrokerFactoryBean
 
isSlowConsumer() - Method in interface org.activemq.broker.BrokerClient
Get an indication if the peer should be considered as a slow consumer
isSlowConsumer() - Method in class org.activemq.broker.impl.BrokerClientImpl
Get an indication if the peer should be considered as a slow consumer
isStarted() - Method in class org.activemq.ActiveMQConnection
 
isStarted() - Method in class org.activemq.advisories.TempDestinationAdvisoryEvent
 
isStarted() - Method in class org.activemq.broker.impl.DefaultBroker
 
isStarted() - Method in class org.activemq.io.util.MemoryBoundedQueue
 
isStarted() - Method in class org.activemq.io.util.SpooledBoundedActiveMQMessageQueue
 
isStarted() - Method in class org.activemq.message.ConnectionInfo
 
isStarted() - Method in class org.activemq.message.ConsumerInfo
 
isStarted() - Method in class org.activemq.message.ProducerInfo
 
isStarted() - Method in class org.activemq.message.SessionInfo
 
isStoreNonPersistentMessages() - Method in class org.activemq.service.DeadLetterPolicy
 
isSupportJMSPriority() - Method in class org.activemq.io.util.MemoryBoundedObjectManager
 
isTarget(ActiveMQMessage) - Method in class org.activemq.ActiveMQConnectionConsumer
Tests to see if the Message Dispatcher is a target for this message
isTarget(ActiveMQMessage) - Method in interface org.activemq.ActiveMQMessageDispatcher
Tests to see if the Message Dispatcher is a target for this message
isTarget(ActiveMQMessage) - Method in class org.activemq.ActiveMQSession
Tests to see if the Message Dispatcher is a target for this message
isTarget(ActiveMQMessage) - Method in class org.activemq.service.boundedvm.DurableQueueSubscription
determines if the Subscription is interested in the message
isTarget(ActiveMQMessage) - Method in class org.activemq.service.boundedvm.DurableSubscription
determines if the Subscription is interested in the message
isTarget(ActiveMQMessage) - Method in class org.activemq.service.boundedvm.TransientQueueSubscription
determines if the Subscription is interested in the message
isTarget(ActiveMQMessage) - Method in class org.activemq.service.boundedvm.TransientSubscription
determines if the Subscription is interested in the message
isTarget(ActiveMQMessage) - Method in class org.activemq.service.boundedvm.TransientTopicSubscription
determines if the Subscription is interested in the message
isTarget(ActiveMQMessage) - Method in class org.activemq.service.impl.SubscriptionImpl
determines if the Subscription is interested in the message
isTarget(ActiveMQMessage) - Method in interface org.activemq.service.Subscription
determines if the Subscription is interested in the message
isTempDestinationAdvisory() - Method in class org.activemq.message.ActiveMQDestination
 
isTemporary() - Method in class org.activemq.message.ActiveMQDestination
Returns true if a temporary Destination
isTemporary() - Method in class org.activemq.message.ActiveMQMessage
 
isTemporary() - Method in class org.activemq.message.ActiveMQTemporaryQueue
Returns true if a temporary Destination
isTemporary() - Method in class org.activemq.message.ActiveMQTemporaryTopic
Returns true if a temporary Destination
isTemporary() - Method in class org.activemq.message.MessageAck
 
isTopic() - Method in class org.activemq.message.ActiveMQDestination
Returns true if a Topic Destination
isTopic() - Method in class org.activemq.message.ActiveMQQueue
Returns true if a Topic Destination
isTopic() - Method in class org.activemq.message.ActiveMQTemporaryQueue
Returns true if a Topic Destination
isTransacted() - Method in class org.activemq.ActiveMQSession
 
isTransacted() - Method in class org.activemq.pool.SessionKey
 
isTransactional() - Method in class org.activemq.management.JMSConnectionStatsImpl
 
isTransientConsumed() - Method in class org.activemq.message.ActiveMQMessage
 
isTransientSubscriber() - Method in class org.activemq.ActiveMQMessageConsumer
 
isTransportConnected() - Method in class org.activemq.transport.composite.CompositeTransportChannel
 
isTransportConnected() - Method in class org.activemq.transport.peer.PeerTransportChannel
 
isTransportConnected() - Method in class org.activemq.transport.remote.RemoteTransportChannel
 
isTransportConnected() - Method in interface org.activemq.transport.TransportChannel
 
isTransportConnected() - Method in class org.activemq.transport.TransportChannelSupport
 
isTurboBoost() - Method in class org.activemq.ActiveMQConnectionFactory
 
isUseAsyncSend() - Method in class org.activemq.ActiveMQConnection
 
isUseAsyncSend() - Method in class org.activemq.ActiveMQConnectionFactory
 
isUseAsyncSend() - Method in class org.activemq.transport.tcp.TcpTransportChannel
 
isUseAsyncSend() - Method in class org.activemq.transport.tcp.TcpTransportServerChannel
 
isUseDatabaseLocking() - Method in class org.activemq.service.DeadLetterPolicy
 
isUsedInternally() - Method in interface org.activemq.transport.TransportChannel
 
isUsedInternally() - Method in class org.activemq.transport.TransportChannelSupport
 
isUseEmbeddedBroker() - Method in class org.activemq.ActiveMQConnectionFactory
Is an embedded broker used by this connection factory
isValid(ActiveMQDestination) - Method in class org.activemq.service.impl.InitialImageMessageContainerManager
Does this message match the destinations on which initial image caching should be used
isWildcard() - Method in class org.activemq.filter.AndFilter
 
isWildcard() - Method in class org.activemq.filter.CompositeDestinationFilter
 
isWildcard() - Method in class org.activemq.filter.ExpressionFilter
 
isWildcard() - Method in interface org.activemq.filter.Filter
 
isWildcard() - Method in class org.activemq.filter.NoLocalFilter
 
isWildcard() - Method in class org.activemq.filter.NotFilter
 
isWildcard() - Method in class org.activemq.filter.OrFilter
 
isWildcard() - Method in class org.activemq.filter.PrefixDestinationFilter
 
isWildcard() - Method in class org.activemq.filter.SimpleDestinationFilter
 
isWildcard() - Method in class org.activemq.filter.WildcardDestinationFilter
 
isWildcard() - Method in class org.activemq.message.ActiveMQDestination
 
isWildcard() - Method in class org.activemq.service.impl.SubscriptionImpl
 
isWildcard() - Method in interface org.activemq.service.Subscription
 
isXaTransacted() - Method in class org.activemq.message.ActiveMQMessage
 
isXaTransacted() - Method in class org.activemq.message.MessageAck
 
isXaTransacted() - Method in class org.activemq.service.impl.AutoCommitTransaction
 
isXaTransacted() - Method in class org.activemq.service.impl.LocalTransactionCommand
 
isXaTransacted() - Method in class org.activemq.service.impl.XATransactionCommand
 
isXaTransacted() - Method in interface org.activemq.service.Transaction
 
itemExists(String) - Method in class org.activemq.message.ActiveMQMapMessage
Indicates whether an item exists in this MapMessage object.

J

J2EEcompliant - Variable in class org.activemq.ActiveMQConnectionFactory
 
JabberTransportChannel - Class in org.activemq.transport.jabber
A transport for using Jabber (XMPP) to talk to ActiveMQ
JabberTransportChannel() - Constructor for class org.activemq.transport.jabber.JabberTransportChannel
 
JabberTransportChannel(URI) - Constructor for class org.activemq.transport.jabber.JabberTransportChannel
 
JabberTransportChannel(URI, URI) - Constructor for class org.activemq.transport.jabber.JabberTransportChannel
 
JabberTransportChannel(TcpTransportServerChannel, Socket, Executor) - Constructor for class org.activemq.transport.jabber.JabberTransportChannel
 
JabberTransportChannel(Socket, Executor) - Constructor for class org.activemq.transport.jabber.JabberTransportChannel
 
JabberTransportChannelFactory - Class in org.activemq.transport.jabber
A Jabber transport factory
JabberTransportChannelFactory() - Constructor for class org.activemq.transport.jabber.JabberTransportChannelFactory
 
JabberTransportServerChannel - Class in org.activemq.transport.jabber
A Jabber server connector
JabberTransportServerChannel(URI) - Constructor for class org.activemq.transport.jabber.JabberTransportServerChannel
 
JabberTransportServerChannel(ServerSocket) - Constructor for class org.activemq.transport.jabber.JabberTransportServerChannel
 
JabberTransportServerChannelFactory - Class in org.activemq.transport.jabber
A JAbber transport factory
JabberTransportServerChannelFactory() - Constructor for class org.activemq.transport.jabber.JabberTransportServerChannelFactory
 
JabberWireFormat - Class in org.activemq.transport.jabber
A wire format which uses XMPP format of messages
JabberWireFormat() - Constructor for class org.activemq.transport.jabber.JabberWireFormat
 
JassJaccSecurityAdapter - Class in org.activemq.security.jassjacc
Implements SecurityAdapter that uses JASS to authenticate and JACC to authorize the user operations.
JassJaccSecurityAdapter(String) - Constructor for class org.activemq.security.jassjacc.JassJaccSecurityAdapter
 
JAXPXPathEvaluator - Class in org.activemq.filter
 
JAXPXPathEvaluator(String) - Constructor for class org.activemq.filter.JAXPXPathEvaluator
 
JCAConnectionPoolStatsImpl - Class in org.activemq.management
Statistics for a JCA connection pool
JCAConnectionPoolStatsImpl(String, String, TimeStatisticImpl, TimeStatisticImpl, CountStatisticImpl, CountStatisticImpl, BoundedRangeStatisticImpl, BoundedRangeStatisticImpl, RangeStatisticImpl) - Constructor for class org.activemq.management.JCAConnectionPoolStatsImpl
 
JCAConnectionStatsImpl - Class in org.activemq.management
Statistics for a JCA connection
JCAConnectionStatsImpl(String, String, TimeStatisticImpl, TimeStatisticImpl) - Constructor for class org.activemq.management.JCAConnectionStatsImpl
 
JCAStatsImpl - Class in org.activemq.management
Statistics for a number of JCA connections and connection pools
JCAStatsImpl(JCAConnectionStatsImpl[], JCAConnectionPoolStatsImpl[]) - Constructor for class org.activemq.management.JCAStatsImpl
 
JDBCAdapter - Interface in org.activemq.store.jdbc
 
JDBCAdapter.ExpiredMessageResultHandler - Interface in org.activemq.store.jdbc
 
JDBCAdapter.MessageListResultHandler - Interface in org.activemq.store.jdbc
 
JDBCMessageStore - Class in org.activemq.store.jdbc
 
JDBCMessageStore(JDBCPersistenceAdapter, JDBCAdapter, WireFormat, String) - Constructor for class org.activemq.store.jdbc.JDBCMessageStore
 
JDBCPersistenceAdapter - Class in org.activemq.store.jdbc
A PersistenceAdapter implementation using JDBC for persistence storage.
JDBCPersistenceAdapter() - Constructor for class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
JDBCPersistenceAdapter(DataSource, WireFormat) - Constructor for class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
JDBCTopicMessageStore - Class in org.activemq.store.jdbc
 
JDBCTopicMessageStore(JDBCPersistenceAdapter, JDBCAdapter, WireFormat, String) - Constructor for class org.activemq.store.jdbc.JDBCTopicMessageStore
 
jj_nt - Variable in class org.activemq.selector.SelectorParser
 
jjstrLiteralImages - Static variable in class org.activemq.selector.SelectorParserTokenManager
 
JMS_PUBLISH_ERROR_CODE - Static variable in class org.activemq.util.JmsLogAppenderSupport
 
JMSBrokerPermission - Class in org.activemq.security.jassjacc
Used to define permissions needed to operate against the ActiveMQ broker.
JMSBrokerPermission(String, String) - Constructor for class org.activemq.security.jassjacc.JMSBrokerPermission
 
JMSConnectionStatsImpl - Class in org.activemq.management
Statistics for a JMS connection
JMSConnectionStatsImpl(List, boolean) - Constructor for class org.activemq.management.JMSConnectionStatsImpl
 
JMSConsumerStatsImpl - Class in org.activemq.management
Statistics for a JMS consumer
JMSConsumerStatsImpl(JMSSessionStatsImpl, Destination) - Constructor for class org.activemq.management.JMSConsumerStatsImpl
 
JMSConsumerStatsImpl(CountStatisticImpl, CountStatisticImpl, CountStatisticImpl, TimeStatisticImpl, TimeStatisticImpl, String) - Constructor for class org.activemq.management.JMSConsumerStatsImpl
 
JMSDestinationPermission - Class in org.activemq.security.jassjacc
Used to define permissions needed to operate against the ActiveMQ destinations.
JMSDestinationPermission(String, String) - Constructor for class org.activemq.security.jassjacc.JMSDestinationPermission
 
JMSDestinationStats - Interface in org.activemq.management
A simple interface to allow statistics gathering to be easily switched out for performance reasons.
JMSEndpointStatsImpl - Class in org.activemq.management
Statistics for a JMS endpoint, typically a MessageProducer or MessageConsumer but this class can also be used to represent statistics on a Destination as well.
JMSEndpointStatsImpl(JMSSessionStatsImpl) - Constructor for class org.activemq.management.JMSEndpointStatsImpl
This constructor is used to create statistics for a MessageProducer or MessageConsumer as it passes in a Session parent statistic.
JMSEndpointStatsImpl() - Constructor for class org.activemq.management.JMSEndpointStatsImpl
This constructor is typically used to create a statistics object for a Destination
JMSEndpointStatsImpl(CountStatisticImpl, CountStatisticImpl, CountStatisticImpl, TimeStatisticImpl, TimeStatisticImpl) - Constructor for class org.activemq.management.JMSEndpointStatsImpl
 
JMSExceptionHelper - Class in org.activemq.util
A helper class for creating new JMS exceptions
JMSExceptionHelper() - Constructor for class org.activemq.util.JMSExceptionHelper
 
JMSInputStream - Class in org.activemq.streams
An inputStream that reads data from a MessageConsumer
JMSInputStream(MessageConsumer) - Constructor for class org.activemq.streams.JMSInputStream
Construct an input stream to read from a JMS Consumer
JmsLogAppender - Class in org.activemq.util
A JMS 1.1 log4j appender which uses ActiveMQ by default and does not require any JNDI configurations
JmsLogAppender() - Constructor for class org.activemq.util.JmsLogAppender
 
JmsLogAppenderSupport - Class in org.activemq.util
An abstract base class for implementation inheritence for a log4j JMS appender
JmsLogAppenderSupport() - Constructor for class org.activemq.util.JmsLogAppenderSupport
 
JMSOutputStream - Class in org.activemq.streams
OutputStream that writes on to JMS via the supplied JMS MessageProducer
JMSOutputStream(MessageProducer) - Constructor for class org.activemq.streams.JMSOutputStream
Creates a new output stream to write data using the supplied JMS MessageProducer
JMSOutputStream(MessageProducer, int) - Constructor for class org.activemq.streams.JMSOutputStream
Creates a new output stream to write data using the supplied JMS MessageProducer
JMSProducerStatsImpl - Class in org.activemq.management
Statistics for a JMS producer
JMSProducerStatsImpl(JMSSessionStatsImpl, Destination) - Constructor for class org.activemq.management.JMSProducerStatsImpl
 
JMSProducerStatsImpl(CountStatisticImpl, CountStatisticImpl, CountStatisticImpl, TimeStatisticImpl, TimeStatisticImpl, String) - Constructor for class org.activemq.management.JMSProducerStatsImpl
 
JMSQueueStatsImpl - Class in org.activemq.management
Statistics for a Queue
JMSQueueStatsImpl() - Constructor for class org.activemq.management.JMSQueueStatsImpl
 
JMSQueueStatsImpl(CountStatisticImpl, CountStatisticImpl, CountStatisticImpl, TimeStatisticImpl, TimeStatisticImpl, TimeStatisticImpl) - Constructor for class org.activemq.management.JMSQueueStatsImpl
 
JmsSelector() - Method in class org.activemq.selector.SelectorParser
 
JMSSessionStatsImpl - Class in org.activemq.management
Statistics for a JMS session
JMSSessionStatsImpl(List, List) - Constructor for class org.activemq.management.JMSSessionStatsImpl
 
JMSStatsImpl - Class in org.activemq.management
Statistics for a number of JMS connections
JMSStatsImpl() - Constructor for class org.activemq.management.JMSStatsImpl
 
JMSTopicStatsImpl - Class in org.activemq.management
Statistics for a Topic
JMSTopicStatsImpl() - Constructor for class org.activemq.management.JMSTopicStatsImpl
 
JNDIBaseStorable - Class in org.activemq.jndi
Faciliates objects to be stored in JNDI as properties
JNDIBaseStorable() - Constructor for class org.activemq.jndi.JNDIBaseStorable
 
JndiJmsLogAppender - Class in org.activemq.util
A JMS 1.1 log4j appender which uses JNDI to locate a JMS ConnectionFactory to use for logging events.
JndiJmsLogAppender() - Constructor for class org.activemq.util.JndiJmsLogAppender
 
JNDIReferenceFactory - Class in org.activemq.jndi
Converts objects implementing JNDIStorable into a property fields so they can be stored and regenerated from JNDI
JNDIReferenceFactory() - Constructor for class org.activemq.jndi.JNDIReferenceFactory
 
JNDIStorableInterface - Interface in org.activemq.jndi
Faciliates objects to be stored in JNDI as properties
JOIN - Static variable in interface org.activemq.message.TransactionType
Join a transaction
JournalAck - Class in org.activemq.store.journal
 
JournalAck(String, String, String, Object) - Constructor for class org.activemq.store.journal.JournalAck
 
JournalMessageStore - Class in org.activemq.store.journal
A MessageStore that uses a Journal to store it's messages.
JournalMessageStore(JournalPersistenceAdapter, MessageStore, String) - Constructor for class org.activemq.store.journal.JournalMessageStore
 
JournalPersistenceAdapter - Class in org.activemq.store.journal
An implementation of PersistenceAdapter designed for use with a Journal and then checkpointing asynchronously on a timeout with some other long term persistent storage.
JournalPersistenceAdapter() - Constructor for class org.activemq.store.journal.JournalPersistenceAdapter
 
JournalPersistenceAdapter(File, PersistenceAdapter) - Constructor for class org.activemq.store.journal.JournalPersistenceAdapter
 
JournalTopicMessageStore - Class in org.activemq.store.journal
A MessageStore that uses a Journal to store it's messages.
JournalTopicMessageStore(JournalPersistenceAdapter, TopicMessageStore, String) - Constructor for class org.activemq.store.journal.JournalTopicMessageStore
 
JournalTransactionStore - Class in org.activemq.store.journal
 
JournalTransactionStore(JournalPersistenceAdapter) - Constructor for class org.activemq.store.journal.JournalTransactionStore
 
JournalTransactionStore.AddMessageCommand - Interface in org.activemq.store.journal
 
JournalTransactionStore.RemoveMessageCommand - Interface in org.activemq.store.journal
 
JournalTransactionStore.Tx - Class in org.activemq.store.journal
Operations
JournalTransactionStore.Tx(RecordLocation) - Constructor for class org.activemq.store.journal.JournalTransactionStore.Tx
 
JournalTransactionStore.TxOperation - Class in org.activemq.store.journal
 
JournalTransactionStore.TxOperation(byte, JournalMessageStore, Object) - Constructor for class org.activemq.store.journal.JournalTransactionStore.TxOperation
 

K

KEEP_ALIVE - Static variable in interface org.activemq.message.Packet
Keep-alive message
KeepAlive - Class in org.activemq.message
Keep-alive packet which holds not information and is only intended to keep connections from being idle.
KeepAlive() - Constructor for class org.activemq.message.KeepAlive
 
KeepAliveDaemon - Class in org.activemq.transport.reliable
KeepAliveDaemon keeps channels alive by sending KeepAlive packets on a specified interval.
KeepAliveDaemon() - Constructor for class org.activemq.transport.reliable.KeepAliveDaemon
Constructs a new KeepAliveDaemon which will send KeepAlive packets throught the wrapped channel.
keepAliveReader - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
KeepAliveReader - Class in org.activemq.io.impl
Reads a KeepAlive packet from a stream
KeepAliveReader() - Constructor for class org.activemq.io.impl.KeepAliveReader
 
keepAliveWriter - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
KeepAliveWriter - Class in org.activemq.io.impl
Writes a KeepAlive object to a Stream
KeepAliveWriter() - Constructor for class org.activemq.io.impl.KeepAliveWriter
 
key - Variable in class org.activemq.service.impl.QueueListSupport.Node
 
kind - Variable in class org.activemq.selector.Token
An integer that describes the kind of this token.

L

lastIndexOf(Object) - Method in class org.activemq.service.impl.DefaultQueueList
 
lastIndexOf(Object) - Method in class org.activemq.service.impl.QueueListSupport
 
lastIndexOf(Object) - Method in interface org.activemq.service.QueueList
Returns the index in this list of the last occurrence of the specified element, or -1 if the list does not contain this element.
lastKeyValue - Variable in class org.activemq.service.impl.QueueListSupport.Header
 
lastLocation - Variable in class org.activemq.store.journal.JournalMessageStore
 
lastMessageIdentity - Variable in class org.activemq.service.impl.SubscriptionImpl
 
lastMessageIdentity - Variable in class org.activemq.store.vm.VMMessageStore
 
lastWriteValueCacheEvictionPosition - Variable in class org.activemq.io.impl.DefaultWireFormat
 
LazyCreateContext - Class in org.activemq.jndi
Allows users to dynamically create items
LazyCreateContext() - Constructor for class org.activemq.jndi.LazyCreateContext
 
left - Variable in class org.activemq.filter.BinaryExpression
 
length() - Method in class org.activemq.util.BitArray
 
lexStateNames - Static variable in class org.activemq.selector.SelectorParserTokenManager
 
LIKE - Static variable in interface org.activemq.selector.SelectorParserConstants
 
LINE_COMMENT - Static variable in interface org.activemq.selector.SelectorParserConstants
 
list(String) - Method in class org.activemq.jndi.ReadOnlyContext
 
list(Name) - Method in class org.activemq.jndi.ReadOnlyContext
 
listAckedMessages() - Method in class org.activemq.service.boundedvm.DurableQueueSubscription
 
listAckedMessages() - Method in class org.activemq.service.boundedvm.TransientQueueSubscription
Get a list of all the acked messages
listBindings(String) - Method in class org.activemq.jndi.ReadOnlyContext
 
listBindings(Name) - Method in class org.activemq.jndi.ReadOnlyContext
 
listeners - Variable in class org.activemq.transport.DiscoveryAgentSupport
 
listMessageContainerAdmin() - Method in interface org.activemq.broker.BrokerAdmin
 
listMessageContainerAdmin() - Method in class org.activemq.broker.impl.DefaultBroker
 
literal() - Method in class org.activemq.selector.SelectorParser
 
loadAllMessageContainers() - Method in class org.activemq.service.impl.DurableTopicMessageContainerManager
Called when recovering a wildcard subscription where we need to load all the durable message containers (for which we have any outstanding messages to deliver) into RAM
loadClass(String, boolean) - Method in class org.activemq.broker.impl.DefaultBroker
Tries to load the given class from the current context class loader or class loader which loaded us or return null if the class could not be found
loadClass(Object, String) - Static method in class org.activemq.jndi.JNDIReferenceFactory
Retrieve the class loader for a named class
loadClass(String, ClassLoader) - Static method in class org.activemq.util.ClassLoading
Load a class for the given name.
loadClass(String) - Method in class org.activemq.util.FactoryFinder
 
loadContainer(String, Destination) - Method in class org.activemq.service.impl.MessageContainerManagerSupport
Loads the container for the given name and destination on startup
LOCAL_COMMIT - Static variable in class org.activemq.store.journal.TxCommand
 
LOCAL_ROLLBACK - Static variable in class org.activemq.store.journal.TxCommand
 
LocalBrokerInfo - Class in org.activemq.broker.impl
Information about a connected Broker
LocalBrokerInfo(DefaultBroker) - Constructor for class org.activemq.broker.impl.LocalBrokerInfo
Constructor
localConnection - Variable in class org.activemq.transport.NetworkChannel
 
LocalTransactionCommand - Class in org.activemq.service.impl
 
LocalTransactionCommand(Map, String, TransactionStore) - Constructor for class org.activemq.service.impl.LocalTransactionCommand
 
LocalTransactionEventListener - Interface in org.activemq
 
lock - Variable in class org.activemq.message.ReceiptHolder
 
logger - Variable in class org.activemq.spring.ActiveMQDtdResolver
 
LogicExpression - Class in org.activemq.filter
A filter performing a comparison of two objects
LogicExpression(BooleanExpression, BooleanExpression) - Constructor for class org.activemq.filter.LogicExpression
 
LOGIN - Static variable in interface org.activemq.transport.stomp.Stomp.Headers.Connect
 
LONG - Static variable in class org.activemq.filter.ArithmeticExpression
 
LONG_SEQUENCE_INDEX - Static variable in class org.activemq.message.ActiveMQMessage
 
LONG_SEQUENCE_INDEX - Static variable in class org.activemq.message.MessageAck
 
longDataType - Variable in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
LongSequenceGenerator - Class in org.activemq.util
Generates sequence ids used to identify messages in the SQL tables.
LongSequenceGenerator() - Constructor for class org.activemq.util.LongSequenceGenerator
 
longTermStore - Variable in class org.activemq.store.journal.JournalMessageStore
 
lookingAhead - Variable in class org.activemq.selector.SelectorParser
 
lookup(String) - Method in class org.activemq.jndi.LazyCreateContext
 
lookup(String) - Method in class org.activemq.jndi.ReadOnlyContext
 
lookup(Name) - Method in class org.activemq.jndi.ReadOnlyContext
 
lookupLink(String) - Method in class org.activemq.jndi.ReadOnlyContext
 
lookupLink(Name) - Method in class org.activemq.jndi.ReadOnlyContext
 
LRUCache - Class in org.activemq.util
Represnts an LRUCache of a fixed maximum size which by default will remove items based on access order but can be used to use insertion order
LRUCache(int, float, boolean, int) - Constructor for class org.activemq.util.LRUCache
 
LRUCache(int) - Constructor for class org.activemq.util.LRUCache
 
LRUCache(int, boolean) - Constructor for class org.activemq.util.LRUCache
 

M

MAGIC - Static variable in class org.activemq.message.WireFormatInfo
 
Main - Class in org.activemq.broker.impl
A simple command line tool which runs a JMS Message Broker on the command line
Main() - Constructor for class org.activemq.broker.impl.Main
 
main(String[]) - Static method in class org.activemq.broker.impl.Main
run the Message Broker as a standalone application
Main - Class in org.activemq.spring
A simple command line tool which runs a JMS Message Broker on the command line using a Spring XML deployment descriptor
Main() - Constructor for class org.activemq.spring.Main
 
main(String[]) - Static method in class org.activemq.spring.Main
run the Message Broker as a standalone application
main(String[]) - Static method in class org.activemq.transport.multicast.MulticastTester
 
makeConnection() - Static method in class org.activemq.ActiveMQConnection
A static helper method to create a new connection
makeConnection(String) - Static method in class org.activemq.ActiveMQConnection
A static helper method to create a new connection
makeConnection(String, String, String) - Static method in class org.activemq.ActiveMQConnection
A static helper method to create a new connection
makeDefaultContainerManagers() - Method in class org.activemq.broker.impl.DefaultBroker
 
makeMap() - Static method in class org.activemq.store.vm.VMTopicMessageStore
 
makeObject() - Method in class org.activemq.pool.SessionPool
 
makeSubscription(Dispatcher, BrokerClient, ConsumerInfo, Filter) - Method in class org.activemq.service.impl.SubscriptionContainerImpl
 
makeSubscription(Dispatcher, BrokerClient, ConsumerInfo, Filter) - Method in interface org.activemq.service.SubscriptionContainer
Creates a subscription (which could be a previous subscription reconecting) and adds it to this container
MapHelper - Class in org.activemq.util
A bunch of utility methods for working with maps
MapHelper() - Constructor for class org.activemq.util.MapHelper
 
mapMessageReader - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
mapMessageWriter - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
mark(int) - Method in class org.activemq.streams.JMSInputStream
Set the stream's mark to the current position.
markSupported() - Method in class org.activemq.streams.JMSInputStream
 
matches(Message) - Method in class org.activemq.filter.AndFilter
 
matches(Destination) - Method in class org.activemq.filter.CompositeDestinationFilter
 
matches(Message) - Method in class org.activemq.filter.DestinationFilter
 
matches(Destination) - Method in class org.activemq.filter.DestinationFilter
 
matches(Message) - Method in class org.activemq.filter.ExpressionFilter
 
matches(Message) - Method in interface org.activemq.filter.Filter
 
matches(Message) - Method in class org.activemq.filter.NoLocalFilter
ensure messages are filtered if they have the same clientId as the filter
matches(Message) - Method in class org.activemq.filter.NotFilter
 
matches(Message) - Method in class org.activemq.filter.OrFilter
 
matches(Destination) - Method in class org.activemq.filter.PrefixDestinationFilter
 
matches(Destination) - Method in class org.activemq.filter.SimpleDestinationFilter
 
matches(Destination) - Method in class org.activemq.filter.WildcardDestinationFilter
 
matches(ActiveMQDestination) - Method in class org.activemq.message.ActiveMQDestination
 
maximumRetries - Variable in class org.activemq.transport.composite.CompositeTransportChannel
 
maximumRetries - Variable in class org.activemq.transport.NetworkChannel
 
maximumTimeout - Variable in class org.activemq.transport.composite.CompositeTransportChannel
 
MemoryBoundedCachePersistenceAdapter - Class in org.activemq.store.cache
Provides a CachePersistenceAdapter that uses a MemoryBoundedLRUCache for each destination.
MemoryBoundedCachePersistenceAdapter() - Constructor for class org.activemq.store.cache.MemoryBoundedCachePersistenceAdapter
 
MemoryBoundedCachePersistenceAdapter(PersistenceAdapter) - Constructor for class org.activemq.store.cache.MemoryBoundedCachePersistenceAdapter
 
MemoryBoundedMessageCache - Class in org.activemq.io.util
A simple cache that stores messages in memory.
MemoryBoundedMessageCache(MemoryBoundedObjectManager) - Constructor for class org.activemq.io.util.MemoryBoundedMessageCache
 
MemoryBoundedObject - Interface in org.activemq.io.util
 
MemoryBoundedObjectManager - Class in org.activemq.io.util
Keeps track of MemoryBoundedObjects
MemoryBoundedObjectManager(String, long) - Constructor for class org.activemq.io.util.MemoryBoundedObjectManager
 
MemoryBoundedObjectManager(String, long, boolean) - Constructor for class org.activemq.io.util.MemoryBoundedObjectManager
 
MemoryBoundedPrioritizedQueue - Class in org.activemq.io.util
 
MemoryBoundedPrioritizedQueue(MemoryBoundedQueueManager, String) - Constructor for class org.activemq.io.util.MemoryBoundedPrioritizedQueue
Constructor
MemoryBoundedQueue - Class in org.activemq.io.util
MemoryBoundedQueue is a queue bounded by memory usage for MemoryManageables
MemoryBoundedQueue(MemoryBoundedQueueManager, String) - Constructor for class org.activemq.io.util.MemoryBoundedQueue
Constructor
MemoryBoundedQueueManager - Class in org.activemq.io.util
A factory manager for MemoryBoundedQueue and also ensures that the maximum memory used by all active MemoryBoundedQueues created by this instance stays within the memory usage bounds set.
MemoryBoundedQueueManager(MemoryBoundedObjectManager) - Constructor for class org.activemq.io.util.MemoryBoundedQueueManager
 
MemoryManageable - Interface in org.activemq.io.util
 
MESSAGE - Static variable in interface org.activemq.transport.stomp.Stomp.Headers.Error
 
MESSAGE - Static variable in interface org.activemq.transport.stomp.Stomp.Responses
 
MESSAGE_ID - Static variable in interface org.activemq.transport.stomp.Stomp.Headers.Ack
 
MESSAGE_ID - Static variable in interface org.activemq.transport.stomp.Stomp.Headers.Message
 
MESSAGE_PART_INDEX - Static variable in class org.activemq.message.ActiveMQMessage
 
MESSAGE_READ_INDEX - Static variable in class org.activemq.message.MessageAck
 
MessageAck - Class in org.activemq.message
Denotes an object that can be serialized/deserailized using a PacketReader/PacketWriter
MessageAck() - Constructor for class org.activemq.message.MessageAck
 
MessageAcknowledge - Interface in org.activemq.message
Called when a Message is Acknowledged
messageAckReader - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
MessageAckReader - Class in org.activemq.io.impl
Reads a ConsumerInfo object from a Stream
messageAckWriter - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
MessageAckWriter - Class in org.activemq.io.impl
Writes a ConsumerInfo object to a Stream
MessageCache - Interface in org.activemq.store.cache
Defines the interface used to cache messages.
messageCompressionLevel - Variable in class org.activemq.ActiveMQConnectionFactory
 
messageCompressionLimit - Variable in class org.activemq.ActiveMQConnectionFactory
 
messageCompressionStrategy - Variable in class org.activemq.ActiveMQConnectionFactory
 
messageConsumed(MessageAck) - Method in class org.activemq.service.impl.DurableTopicSubscription
 
messageConsumed(MessageAck) - Method in class org.activemq.service.impl.SubscriptionImpl
Indicates a message has been delivered to a MessageConsumer
messageConsumed(MessageAck) - Method in interface org.activemq.service.Subscription
Indicates a message has been delivered to a MessageConsumer which is typically called for topic based subscriptions
MessageContainer - Interface in org.activemq.service
A MessageContainer holds the messages for a particular destination
MessageContainerAdmin - Interface in org.activemq.service
Provides a admin view to a destination.
MessageContainerManager - Interface in org.activemq.service
A manager of MessageContainer instances
MessageContainerManagerSupport - Class in org.activemq.service.impl
 
MessageContainerManagerSupport(Dispatcher) - Constructor for class org.activemq.service.impl.MessageContainerManagerSupport
 
messageContainers - Variable in class org.activemq.service.impl.MessageContainerManagerSupport
 
messageCount - Variable in class org.activemq.management.JMSEndpointStatsImpl
 
MessageEntry - Class in org.activemq.service.impl
An entry for a message in a container
MessageEntry() - Constructor for class org.activemq.service.impl.MessageEntry
Only used by serialisation
MessageEntry(ActiveMQMessage) - Constructor for class org.activemq.service.impl.MessageEntry
 
messageFragmentationLimit - Variable in class org.activemq.ActiveMQConnectionFactory
 
MessageIdentity - Class in org.activemq.service
Represents a message identity, either by using a unique message number, which is ordered and must not be zero or by specifying the String messageID.
MessageIdentity() - Constructor for class org.activemq.service.MessageIdentity
 
MessageIdentity(String) - Constructor for class org.activemq.service.MessageIdentity
 
MessageIdentity(String, Object) - Constructor for class org.activemq.service.MessageIdentity
 
MessageListenerSupport - Class in org.activemq.util
A helper base class which makes writing message listeners easier without having to worry about handling the JMSException on the onMessage() method.
MessageListenerSupport() - Constructor for class org.activemq.util.MessageListenerSupport
 
messagePartSubscribers - Variable in class org.activemq.service.impl.DurableQueueMessageContainerManager
 
messagePtrs - Variable in class org.activemq.service.impl.SubscriptionImpl
 
messageQueue - Variable in class org.activemq.ActiveMQConnectionConsumer
 
messageQueue - Variable in class org.activemq.ActiveMQMessageConsumer
 
messageRateTime - Variable in class org.activemq.management.JMSEndpointStatsImpl
 
messageReader - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
messageSelector - Variable in class org.activemq.ActiveMQMessageConsumer
 
MessageStore - Interface in org.activemq.store
Represents a message store which is used by the persistent MessageContainer implementations
messageTable - Variable in class org.activemq.store.vm.VMMessageStore
 
messageTableName - Variable in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
messageWaitTime - Variable in class org.activemq.management.JMSEndpointStatsImpl
 
messageWriter - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
minus(Number, Number) - Method in class org.activemq.filter.ArithmeticExpression
 
mod(Number, Number) - Method in class org.activemq.filter.ArithmeticExpression
 
msgIdDataType - Variable in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
multExpr() - Method in class org.activemq.selector.SelectorParser
 
MulticastDiscoveryAgent - Class in org.activemq.transport.multicast
An agent used to discover other instances of a service
MulticastDiscoveryAgent(String) - Constructor for class org.activemq.transport.multicast.MulticastDiscoveryAgent
Construct a discovery agent that uses multicast
MulticastDiscoveryAgent(URI) - Constructor for class org.activemq.transport.multicast.MulticastDiscoveryAgent
 
MulticastDiscoveryTransportChannelFactory - Class in org.activemq.transport.multicast
A factory of multicast discovery transports
MulticastDiscoveryTransportChannelFactory() - Constructor for class org.activemq.transport.multicast.MulticastDiscoveryTransportChannelFactory
 
MulticastTester - Class in org.activemq.transport.multicast
An agent used to discover other instances of a service
MulticastTester() - Constructor for class org.activemq.transport.multicast.MulticastTester
 
MulticastTransportChannel - Class in org.activemq.transport.multicast
A multicast implementation of a TransportChannel
MulticastTransportChannel(WireFormat, URI) - Constructor for class org.activemq.transport.multicast.MulticastTransportChannel
Connect to a remote Node - e.g.
MulticastTransportChannel(WireFormat, MulticastSocket) - Constructor for class org.activemq.transport.multicast.MulticastTransportChannel
 
MulticastTransportChannelFactory - Class in org.activemq.transport.multicast
A multicast implementation of a TransportChannelFactory
MulticastTransportChannelFactory() - Constructor for class org.activemq.transport.multicast.MulticastTransportChannelFactory
 
MulticastTransportServerChannel - Class in org.activemq.transport.multicast
A Multicast implementation of TransportServerChannel
MulticastTransportServerChannel(WireFormat, URI) - Constructor for class org.activemq.transport.multicast.MulticastTransportServerChannel
 
MulticastTransportServerChannelFactory - Class in org.activemq.transport.multicast
A multicast implementation of a TransportServerChannelFactory
MulticastTransportServerChannelFactory() - Constructor for class org.activemq.transport.multicast.MulticastTransportServerChannelFactory
 
MultiExpressionEvaluator - Class in org.activemq.filter
A MultiExpressionEvaluator is used to evaluate multiple expressions in single method call.
MultiExpressionEvaluator() - Constructor for class org.activemq.filter.MultiExpressionEvaluator
 
MultiExpressionEvaluator.CacheExpression - Class in org.activemq.filter
A UnaryExpression that caches the result of the nested expression.
MultiExpressionEvaluator.CacheExpression(Expression) - Constructor for class org.activemq.filter.MultiExpressionEvaluator.CacheExpression
 
multiply(Number, Number) - Method in class org.activemq.filter.ArithmeticExpression
 

N

nameParser - Static variable in class org.activemq.jndi.ReadOnlyContext
 
NameParserImpl - Class in org.activemq.jndi
A default implementation of NameParser
NameParserImpl() - Constructor for class org.activemq.jndi.NameParserImpl
 
NetworkChannel - Class in org.activemq.transport
Represents a broker's connection with a single remote broker which bridges the two brokers to form a network.
NetworkChannel() - Constructor for class org.activemq.transport.NetworkChannel
Default constructor
NetworkChannel(PooledExecutor) - Constructor for class org.activemq.transport.NetworkChannel
Default Constructor
NetworkChannel(NetworkConnector, BrokerContainer, String) - Constructor for class org.activemq.transport.NetworkChannel
Constructor
NetworkChannel(NetworkConnector, BrokerContainer, TransportChannel, String, String) - Constructor for class org.activemq.transport.NetworkChannel
Create a NetworkConnector from a TransportChannel
NetworkConnector - Class in org.activemq.transport
Represents a connector to one or more remote brokers.
NetworkConnector(BrokerContainer) - Constructor for class org.activemq.transport.NetworkConnector
 
newContext() - Method in class org.activemq.jndi.ReadOnlyContext
 
newFactory(String) - Static method in class org.activemq.spring.SpringBrokerContainerFactory
A helper method, invoked via reflection, to create a new factory from a given configuration file String which if it starts with classpath: is a classpath URI otherwise a URL is assumed.
newInstance() - Method in class org.activemq.pool.PooledConnection
Factory method to create a new instance.
newInstance(String, Resource) - Static method in class org.activemq.spring.ActiveMQBeanFactory
A static factory method which can be used easily from spring.xml
newInstance(Resource) - Static method in class org.activemq.spring.SpringBrokerContainerFactory
A static factory method that can be used in Spring config files using a factory method mechanism to create a broker container easily.
newInstance(Resource, String) - Static method in class org.activemq.spring.SpringBrokerContainerFactory
A static factory method that can be used in Spring config files using a factory method mechanism to create a broker container easily.
newInstance(File) - Static method in class org.activemq.store.vm.VMPersistenceAdapter
 
newInstance(WireFormat, String) - Static method in class org.activemq.transport.TransportServerChannelProvider
Create a Channel used for the Broker to listen to remove connections
newInstance(String) - Method in class org.activemq.util.FactoryFinder
Creates a new instance of the given key
NEWINSTANCE_PARAMETER_TYPES - Static variable in class org.activemq.broker.impl.DefaultBroker
 
newIOException(JMSException) - Static method in class org.activemq.util.JMSExceptionHelper
 
newJMSException(String, Throwable) - Static method in class org.activemq.util.JMSExceptionHelper
 
newJMSException(String, Exception) - Static method in class org.activemq.util.JMSExceptionHelper
 
newJMSException(Throwable) - Static method in class org.activemq.util.JMSExceptionHelper
 
NEWLINE - Static variable in interface org.activemq.transport.stomp.Stomp
 
newThread(Runnable) - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageManager.DurableQueueThreadFactory
 
newThread(Runnable) - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageManager.TransientQueueThreadFactory
 
newToken(int) - Static method in class org.activemq.selector.Token
Returns a new Token object, by default.
next - Variable in class org.activemq.selector.Token
A reference to the next regular (non-special) token from the input stream.
nextByte() - Method in class org.activemq.transport.reliable.SMLCGRandom
 
nextDouble() - Method in class org.activemq.transport.reliable.SMLCGRandom
 
nextElement() - Method in class org.activemq.ActiveMQQueueBrowser
 
nextFloat() - Method in class org.activemq.transport.reliable.SMLCGRandom
 
nextInt() - Method in class org.activemq.transport.reliable.SMLCGRandom
 
nextKey - Variable in class org.activemq.service.impl.QueueListSupport.Node
 
nextLong() - Method in class org.activemq.transport.reliable.SMLCGRandom
 
nextShort() - Method in class org.activemq.transport.reliable.SMLCGRandom
 
NO_DELAY_PROPERTY - Static variable in class org.activemq.message.ConnectionInfo
Hint for transport(s) about message delivery
noDelay - Variable in class org.activemq.transport.TransportChannelSupport
 
noLocal - Variable in class org.activemq.ActiveMQMessageConsumer
 
NoLocalFilter - Class in org.activemq.filter
Checks that messages are not filtered by NoLocal
NoLocalFilter(String) - Constructor for class org.activemq.filter.NoLocalFilter
Construct a NoLocalFilter
NOT - Static variable in interface org.activemq.selector.SelectorParserConstants
 
NOT_SET - Static variable in interface org.activemq.message.Packet
Unspecified Packet type
NOT_SET - Static variable in interface org.activemq.message.TransactionType
Transaction state not set
NotFilter - Class in org.activemq.filter
Represents a logical not operation on another filter
NotFilter(Filter) - Constructor for class org.activemq.filter.NotFilter
 
notified - Variable in class org.activemq.message.ReceiptHolder
 
NotStartedException - Exception in org.activemq
An exception thrown when an operation is invoked on a service which has not yet been started.
NotStartedException() - Constructor for exception org.activemq.NotStartedException
 
NULL - Static variable in class org.activemq.filter.ConstantExpression
 
NULL - Static variable in interface org.activemq.selector.SelectorParserConstants
 
NULL - Static variable in interface org.activemq.transport.stomp.Stomp
 
numberOfActiveConnections() - Method in class org.activemq.advisories.ConnectionAdvisor
return the current number of active connections

O

objectMessageReader - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
objectMessageWriter - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
OCTAL_LITERAL - Static variable in interface org.activemq.selector.SelectorParserConstants
 
onAccept(Channel) - Method in class org.activemq.transport.activeio.ActiveIOTransportServerChannel
 
onAcceptError(IOException) - Method in class org.activemq.transport.activeio.ActiveIOTransportServerChannel
 
onAsyncException(JMSException) - Method in class org.activemq.transport.TransportChannelSupport
Handles an exception thrown while performing async dispatch of messages
onConsumerInfo(BrokerClient, ConsumerInfo) - Method in interface org.activemq.broker.ConsumerInfoListener
ConsumerInfo packet fired from within the broker
onConsumerInfo(BrokerClient, ConsumerInfo) - Method in class org.activemq.transport.NetworkChannel
Listen for new Consumer events at this broker
onCreateDurableSubscriber() - Method in class org.activemq.management.JMSSessionStatsImpl
 
onEvent(ConnectionAdvisoryEvent) - Method in interface org.activemq.advisories.ConnectionAdvisoryEventListener
called when a MessageConnection starts/stops
onEvent(ConsumerAdvisoryEvent) - Method in interface org.activemq.advisories.ConsumerAdvisoryEventListener
called when a MessageConsumer starts/stops
onEvent(ProducerAdvisoryEvent) - Method in interface org.activemq.advisories.ProducerAdvisoryEventListener
called when a MessageProducer starts/stops
onEvent(ProducerDemandEvent) - Method in interface org.activemq.advisories.ProducerDemandListener
Called when a there is a chanage in demand for a destination.
onEvent(TempDestinationAdvisoryEvent) - Method in interface org.activemq.advisories.TempDestinationAdvisoryEventListener
called when a TemporaryDestination starts/stops
onEvent(ConnectionAdvisoryEvent) - Method in class org.activemq.transport.NetworkChannel
Implementation of ConnectionAdvisoryEventListener
onException(JMSException) - Method in class org.activemq.ActiveMQConnection
 
onException(JMSException) - Method in class org.activemq.broker.impl.BrokerClientImpl
 
onException(JMSException) - Method in class org.activemq.transport.reliable.ReliableTransportChannel
handle exception from the embedded channel
onJMSException(JMSException, Message) - Method in class org.activemq.util.MessageListenerSupport
Process the JMS exception either by calling an exception listener which can contian custom logic or by throwing a runtime exception
onMessage(Message) - Method in class org.activemq.advisories.ConnectionAdvisor
OnMessage() implementation
onMessage(Message) - Method in class org.activemq.advisories.ConsumerAdvisor
OnMessage() implementation
onMessage(Message) - Method in class org.activemq.advisories.ProducerAdvisor
OnMessage() implementation
onMessage(Message) - Method in class org.activemq.advisories.TempDestinationAdvisor
OnMessage() implementation
onMessage(Message) - Method in class org.activemq.management.JMSEndpointStatsImpl
 
onMessage(Message) - Method in class org.activemq.spring.TestingConsumer
 
onMessage(long, String, String, boolean) - Method in interface org.activemq.store.jdbc.JDBCAdapter.ExpiredMessageResultHandler
 
onMessage(long, String) - Method in interface org.activemq.store.jdbc.JDBCAdapter.MessageListResultHandler
 
onMessage(Message) - Method in class org.activemq.util.MessageListenerSupport
 
onMessageAck() - Method in interface org.activemq.management.JMSDestinationStats
On a consume from this destination, updates the consumed states
onMessageAck() - Method in class org.activemq.management.JMSQueueStatsImpl
 
onMessageAck() - Method in class org.activemq.management.JMSTopicStatsImpl
 
onMessageSend(Message) - Method in interface org.activemq.management.JMSDestinationStats
On a message send to this destination, update the producing stats
onMessageSend(Message) - Method in class org.activemq.management.JMSQueueStatsImpl
 
onMessageSend(Message) - Method in class org.activemq.management.JMSTopicStatsImpl
 
onPacket(Packet) - Method in class org.activemq.transport.activeio.ActiveIOTransportChannel
 
onPacketError(IOException) - Method in class org.activemq.transport.activeio.ActiveIOTransportChannel
 
onRemoveDurableSubscriber() - Method in class org.activemq.management.JMSSessionStatsImpl
 
operationType - Variable in class org.activemq.store.journal.JournalTransactionStore.TxOperation
 
optimizedMessageDispatch - Variable in class org.activemq.ActiveMQConnectionFactory
 
OR - Static variable in interface org.activemq.selector.SelectorParserConstants
 
OracleJDBCAdapter - Class in org.activemq.store.jdbc.adapter
Implements all the default JDBC operations that are used by the JDBCPersistenceAdapter.
OracleJDBCAdapter() - Constructor for class org.activemq.store.jdbc.adapter.OracleJDBCAdapter
 
OracleJDBCAdapter(StatementProvider) - Constructor for class org.activemq.store.jdbc.adapter.OracleJDBCAdapter
 
orExpression() - Method in class org.activemq.selector.SelectorParser
 
OrFilter - Class in org.activemq.filter
Represents a logical OR operation on two filters
OrFilter(Filter, Filter) - Constructor for class org.activemq.filter.OrFilter
 
org.activemq - package org.activemq
The core JMS client implementation classes
org.activemq.advisories - package org.activemq.advisories
Helper classes for listening to advisory messages.
org.activemq.broker - package org.activemq.broker
The API for the JMS Broker which is the server side of a JMS network though it may be deployed inside a client in peer style networks.
org.activemq.broker.impl - package org.activemq.broker.impl
The default implementation of the JMS Broker
org.activemq.capacity - package org.activemq.capacity
 
org.activemq.filter - package org.activemq.filter
Filter implementations for wildcards & JMS selectors
org.activemq.io - package org.activemq.io
 
org.activemq.io.impl - package org.activemq.io.impl
 
org.activemq.io.util - package org.activemq.io.util
 
org.activemq.jndi - package org.activemq.jndi
JNDI helper classes
org.activemq.management - package org.activemq.management
An implementation of the J2EE Management API
org.activemq.message - package org.activemq.message
Message implementations
org.activemq.pool - package org.activemq.pool
A JMS provider for working with ActiveMQ's JCA ResourceAdapter which uses the same JMS Session that is being used to dispatch JMS Messages inside a JCA or MDB container.
org.activemq.security - package org.activemq.security
Plugable Security Adapter framework along with default implementations such as the JAAS implementation.
org.activemq.security.jassjacc - package org.activemq.security.jassjacc
 
org.activemq.selector - package org.activemq.selector
JMS Selector parser
org.activemq.service - package org.activemq.service
The core services which make up the JMS Message Broker such as the Store, MessageContainer and MessageContainerManager
org.activemq.service.boundedvm - package org.activemq.service.boundedvm
 
org.activemq.service.impl - package org.activemq.service.impl
Default implementations of the services
org.activemq.spring - package org.activemq.spring
Utilities for loading a Message Broker using Spring's XML deployment mechanism
org.activemq.store - package org.activemq.store
The APIs which need to be implemented for persistent message stores for durable messaging
org.activemq.store.cache - package org.activemq.store.cache
 
org.activemq.store.jdbc - package org.activemq.store.jdbc
Message persistence implemented using JDBC
org.activemq.store.jdbc.adapter - package org.activemq.store.jdbc.adapter
Implements database/driver apapters to compensate for the wide differences in the BLOB handing of JDBC drivers.
org.activemq.store.journal - package org.activemq.store.journal
Message persistence using a high performance transaction log via the Journal interface.
org.activemq.store.vm - package org.activemq.store.vm
VM based implementation of message persistence
org.activemq.streams - package org.activemq.streams
 
org.activemq.transport - package org.activemq.transport
The transport abstraction layer for sending and receiving Packets over a network
org.activemq.transport.activeio - package org.activemq.transport.activeio
An implementation of the transport layer using activeio channels see http://activeio.org
org.activemq.transport.composite - package org.activemq.transport.composite
A Composite Pattern implementation of TransportChannel allowing a client to connect randomly to one of a number of possible destinations, cycling through them until a connection is established.
org.activemq.transport.jabber - package org.activemq.transport.jabber
A transport using Jabber (XMPP)
org.activemq.transport.multicast - package org.activemq.transport.multicast
An implementation of the transport layer using multicast
org.activemq.transport.peer - package org.activemq.transport.peer
 
org.activemq.transport.reliable - package org.activemq.transport.reliable
 
org.activemq.transport.remote - package org.activemq.transport.remote
 
org.activemq.transport.stomp - package org.activemq.transport.stomp
An implementation of the Stomp protocol which is a simple wire protocol for writing clients for ActiveMQ in different languages like Ruby, Python, PHP, C etc.
org.activemq.transport.tcp - package org.activemq.transport.tcp
An implementation of the transport layer using TCP/IP sockets
org.activemq.transport.udp - package org.activemq.transport.udp
An implementation of the transport layer using UDP
org.activemq.transport.vm - package org.activemq.transport.vm
An implementation of the transport layer using intra-JVM communication
org.activemq.util - package org.activemq.util
Utility classes like a SEDA style Command pattern helper and a BitArray for working with flags etc.
outLock - Variable in class org.activemq.io.util.MemoryBoundedQueue
 
overflowNotification(RecordLocation) - Method in class org.activemq.store.journal.JournalPersistenceAdapter
The Journal give us a call back so that we can move old data out of the journal.

P

Packet - Interface in org.activemq.message
Denotes an object that can be serialized/deserailized using a PacketReader or PacketWriter
PACKET - Static variable in class org.activemq.transport.stomp.FlushPacket
 
PacketAggregator - Class in org.activemq.transport.activeio
 
PacketAggregator() - Constructor for class org.activemq.transport.activeio.PacketAggregator
 
packetAssembled(Packet) - Method in class org.activemq.transport.activeio.PacketAggregator
 
PacketFacade - Class in org.activemq.message
A helper class for using Packet instances with object serialization
PacketFacade() - Constructor for class org.activemq.message.PacketFacade
 
PacketFacade(Packet) - Constructor for class org.activemq.message.PacketFacade
 
packetIdGenerator - Variable in class org.activemq.ActiveMQConnection
 
PacketListener - Interface in org.activemq.message
Listener for Packets
PacketReader - Interface in org.activemq.io.impl
Allows instances implementing Packet to read from a DataOutputStream
PacketWriter - Interface in org.activemq.io.impl
Allows instances implementing Packet to written to a DataOutput
parse(String) - Method in class org.activemq.jndi.NameParserImpl
 
parse(String) - Method in class org.activemq.selector.SelectorParser
 
ParseException - Exception in org.activemq.selector
This exception is thrown when parse errors are encountered.
ParseException(Token, int[][], String[]) - Constructor for exception org.activemq.selector.ParseException
This constructor is used by the method "generateParseException" in the generated parser.
ParseException() - Constructor for exception org.activemq.selector.ParseException
The following constructors are for use by you for whatever purpose you can think of.
ParseException(String) - Constructor for exception org.activemq.selector.ParseException
 
parseFilter(Destination) - Static method in class org.activemq.filter.DestinationFilter
 
parseQuery(URI) - Static method in class org.activemq.util.URIHelper
Parsers the query string of the URI into a map of key-value pairs
parseQuery(String) - Static method in class org.activemq.util.URIHelper
Parsers the query string of the URI into a map of key-value pairs
parseURIs(List, URI) - Static method in class org.activemq.transport.composite.CompositeTransportChannelFactory
 
parseURIs(URI) - Method in class org.activemq.transport.DiscoveryTransportChannel
 
PASSCODE - Static variable in interface org.activemq.transport.stomp.Stomp.Headers.Connect
 
passivateObject(Object) - Method in class org.activemq.pool.SessionPool
 
password - Variable in class org.activemq.ActiveMQConnectionFactory
 
PAYLOAD_INDEX - Static variable in class org.activemq.message.ActiveMQMessage
 
peekConnection() - Static method in class org.activemq.store.jdbc.TransactionContext
 
peekNext(MessageIdentity) - Method in class org.activemq.service.impl.DurableQueueMessageContainer
 
peekNext(MessageIdentity) - Method in interface org.activemq.service.QueueMessageContainer
Used for browsing a MessageContainer this returns the next message in the container after the messageId
PeerTransportChannel - Class in org.activemq.transport.peer
A PeerTransportChannel creates an embedded broker and networks peers together to form a P-2-P network.
PeerTransportChannel(WireFormat, String) - Constructor for class org.activemq.transport.peer.PeerTransportChannel
Construct a PeerTransportChannel
PeerTransportChannelFactory - Class in org.activemq.transport.peer
Creates peer based transport.
PeerTransportChannelFactory() - Constructor for class org.activemq.transport.peer.PeerTransportChannelFactory
 
peerURIs - Variable in class org.activemq.transport.peer.PeerTransportChannel
 
pendingMessageCount - Variable in class org.activemq.management.JMSEndpointStatsImpl
 
pendingStop - Variable in class org.activemq.transport.TransportChannelSupport
 
peristenceAdapter - Variable in class org.activemq.store.journal.JournalMessageStore
 
PERSISTENCE_ADAPTER_FACTORY - Static variable in class org.activemq.broker.impl.DefaultBroker
 
persistenceAdapter - Variable in class org.activemq.store.jdbc.JDBCMessageStore
 
PersistenceAdapter - Interface in org.activemq.store
Adapter to the actual persistence mechanism used with ActiveMQ
PersistenceAdapterFactory - Interface in org.activemq.store
Factory class that can create PersistenceAdapter objects.
persistent - Variable in class org.activemq.transport.peer.PeerTransportChannel
 
PERSISTENT_INDEX - Static variable in class org.activemq.message.MessageAck
 
plus(Number, Number) - Method in class org.activemq.filter.ArithmeticExpression
 
poll() - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageManager
 
poll() - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageManager
 
poll() - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageManager
 
poll() - Method in class org.activemq.service.impl.DurableQueueMessageContainer
 
poll() - Method in class org.activemq.service.impl.DurableQueueMessageContainerManager
Poll for messages
poll() - Method in class org.activemq.service.impl.DurableTopicMessageContainerManager
poll or messages
poll() - Method in class org.activemq.service.impl.ProxyMessageContainerManager
 
poll() - Method in interface org.activemq.service.MessageContainerManager
Poll for messages
poll() - Method in interface org.activemq.service.QueueMessageContainer
Some implementations may need to poll to fill subscriptions this returns the next message in the container
PooledConnection - Class in org.activemq.pool
Represents a proxy Connection which is-a TopicConnection and QueueConnection which is pooled and on PooledConnection.close() will return itself to the sessionPool.
PooledConnection(ActiveMQConnection) - Constructor for class org.activemq.pool.PooledConnection
 
PooledConnection(ActiveMQConnection, Map) - Constructor for class org.activemq.pool.PooledConnection
 
PooledConnectionFactory - Class in org.activemq.pool
 
PooledConnectionFactory() - Constructor for class org.activemq.pool.PooledConnectionFactory
 
PooledConnectionFactory(String) - Constructor for class org.activemq.pool.PooledConnectionFactory
 
PooledConnectionFactory(ActiveMQConnectionFactory) - Constructor for class org.activemq.pool.PooledConnectionFactory
 
PooledProducer - Class in org.activemq.pool
A pooled MessageProducer
PooledProducer(ActiveMQMessageProducer, Destination) - Constructor for class org.activemq.pool.PooledProducer
 
PooledQueueSender - Class in org.activemq.pool
 
PooledQueueSender(ActiveMQQueueSender, Destination) - Constructor for class org.activemq.pool.PooledQueueSender
 
PooledSession - Class in org.activemq.pool
 
PooledSession(ActiveMQSession, ObjectPool) - Constructor for class org.activemq.pool.PooledSession
 
PooledTopicPublisher - Class in org.activemq.pool
 
PooledTopicPublisher(ActiveMQTopicPublisher, Destination) - Constructor for class org.activemq.pool.PooledTopicPublisher
 
popConnection() - Static method in class org.activemq.store.jdbc.TransactionContext
Pops off the current Connection from the stack
populate(Object, Map) - Static method in class org.activemq.util.BeanUtils
 
populateAgentProperties(DiscoveryAgent, URI) - Method in class org.activemq.transport.DiscoveryTransportChannelFactorySupport
 
populateProperties(Properties) - Method in class org.activemq.ActiveMQConnectionFactory
Initialize the instance from properties stored in JNDI
populateProperties(Properties) - Method in class org.activemq.jndi.JNDIBaseStorable
Initialize the instance from properties stored in JNDI
populateProperties(Properties) - Method in class org.activemq.message.ActiveMQDestination
Initialize the instance from properties stored in JNDI
populateProperties(TransportChannel, URI) - Method in class org.activemq.transport.TransportChannelFactorySupport
If a query string is present in the URI then set any simple bean properties on the channel
populateProperties(TransportChannel, String) - Method in class org.activemq.transport.TransportChannelFactorySupport
If a query string is present in the URI then set any simple bean properties on the channel
populateProperties(TransportChannel, Map) - Method in class org.activemq.transport.TransportChannelFactorySupport
 
port - Variable in class org.activemq.transport.udp.UdpTransportChannel
 
position() - Method in class org.activemq.io.util.WireByteArrayInputStream
 
postCommit() - Method in class org.activemq.service.impl.AbstractTransaction
 
PostgresqlJDBCAdapter - Class in org.activemq.store.jdbc.adapter
Implements all the default JDBC operations that are used by the JDBCPersistenceAdapter.
PostgresqlJDBCAdapter() - Constructor for class org.activemq.store.jdbc.adapter.PostgresqlJDBCAdapter
 
PostgresqlJDBCAdapter(StatementProvider) - Constructor for class org.activemq.store.jdbc.adapter.PostgresqlJDBCAdapter
 
postRollback() - Method in class org.activemq.service.impl.AbstractTransaction
 
PRE_COMMIT - Static variable in interface org.activemq.message.TransactionType
Pre-commit a transaction
prefetchNumber - Variable in class org.activemq.ActiveMQMessageConsumer
 
PrefixDestinationFilter - Class in org.activemq.filter
Matches messages which match a prefix like "A.B.>"
PrefixDestinationFilter(String[]) - Constructor for class org.activemq.filter.PrefixDestinationFilter
An array of paths, the last path is '>'
prepare() - Method in class org.activemq.service.impl.AutoCommitTransaction
 
prepare() - Method in class org.activemq.service.impl.LocalTransactionCommand
 
prepare() - Method in class org.activemq.service.impl.XATransactionCommand
 
prepare() - Method in interface org.activemq.service.Transaction
 
prepare(Object) - Method in class org.activemq.store.journal.JournalTransactionStore
 
prepare(Object) - Method in interface org.activemq.store.TransactionStore
 
prepare(Object) - Method in class org.activemq.store.vm.VMTransactionStore
 
prepare(Xid) - Method in class org.activemq.TransactionContext
 
PREPARED_STATE - Static variable in class org.activemq.service.impl.AbstractTransaction
 
prepareMessageBody() - Method in class org.activemq.message.ActiveMQMessage
Prepare a message body for delivery
prepareMessageBody() - Method in class org.activemq.message.ActiveMQObjectMessage
Prepare a message body for delivery
prepareMessageBodyOnSend - Variable in class org.activemq.ActiveMQConnectionFactory
 
prepareTransaction(BrokerClient, ActiveMQXid) - Method in interface org.activemq.broker.Broker
 
prepareTransaction(BrokerClient, ActiveMQXid) - Method in interface org.activemq.broker.BrokerConnector
Prepare an XA transaction.
prepareTransaction(BrokerClient, ActiveMQXid) - Method in interface org.activemq.broker.BrokerContainer
Prepare an XA transaction.
prepareTransaction(BrokerClient, ActiveMQXid) - Method in class org.activemq.broker.impl.BrokerConnectorImpl
Prepare an XA transaction.
prepareTransaction(BrokerClient, ActiveMQXid) - Method in class org.activemq.broker.impl.BrokerContainerImpl
Prepare an XA transaction.
prepareTransaction(BrokerClient, ActiveMQXid) - Method in class org.activemq.broker.impl.DefaultBroker
Prepares an XA Transaciton.
prePrepare() - Method in class org.activemq.service.impl.AbstractTransaction
 
previousKey - Variable in class org.activemq.service.impl.QueueListSupport.Node
 
primaryExpr() - Method in class org.activemq.selector.SelectorParser
 
print(String) - Method in class org.activemq.util.IndentPrinter
 
printIndent() - Method in class org.activemq.util.IndentPrinter
 
println(Object) - Method in class org.activemq.util.IndentPrinter
 
println(String) - Method in class org.activemq.util.IndentPrinter
 
println() - Method in class org.activemq.util.IndentPrinter
 
process(Message) - Method in class org.activemq.advisories.ProducerDemandAdvisor
 
processMessage(ActiveMQMessage) - Method in class org.activemq.ActiveMQMessageConsumer
Process a Message - passing either to the queue or message listener
processMessage(Message) - Method in class org.activemq.util.MessageListenerSupport
This method processes the incoming message possibly throwing a JMSException if the message could not be processed correctly.
processSubscription(Subscription, QueueMessageContainer) - Method in class org.activemq.service.impl.DurableQueueMessageContainerManager
 
PRODUCE_ACTION - Static variable in class org.activemq.security.jassjacc.JMSDestinationPermission
 
PRODUCER_ADVISORY_PREFIX - Static variable in class org.activemq.message.ActiveMQDestination
Deprecated. Use #getDestinationForProducerAdvisory() instead.
PRODUCER_INFO - Static variable in interface org.activemq.message.Packet
Producer Info
ProducerAdvisor - Class in org.activemq.advisories
A helper class for listening for MessageProducer advisories * @version $Revision: 1.1.1.1 $
ProducerAdvisor(Connection, Destination) - Constructor for class org.activemq.advisories.ProducerAdvisor
Construct a ProducerAdvisor
ProducerAdvisoryEvent - Class in org.activemq.advisories
This event is raised when a MessageProducer starts/stops * @version $Revision: 1.1.1.1 $
ProducerAdvisoryEventListener - Interface in org.activemq.advisories
A Listener for ProducerAdvisoryEvents * @version $Revision: 1.1.1.1 $
ProducerDemandAdvisor - Class in org.activemq.advisories
A ProducerDemandAdvisor is used to know when a destination is in demand.
ProducerDemandAdvisor(Connection, Destination) - Constructor for class org.activemq.advisories.ProducerDemandAdvisor
 
ProducerDemandEvent - Class in org.activemq.advisories
 
ProducerDemandListener - Interface in org.activemq.advisories
 
ProducerInfo - Class in org.activemq.message
Denotes life cycle infomation for a Producer of messages
ProducerInfo() - Constructor for class org.activemq.message.ProducerInfo
 
producerInfoReader - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
ProducerInfoReader - Class in org.activemq.io.impl
Reads a ProducerInfo object from a Stream
ProducerInfoReader() - Constructor for class org.activemq.io.impl.ProducerInfoReader
 
producerInfoWriter - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
ProducerInfoWriter - Class in org.activemq.io.impl
Writes a ProducerInfo object to a Stream
ProducerInfoWriter() - Constructor for class org.activemq.io.impl.ProducerInfoWriter
 
producers - Variable in class org.activemq.ActiveMQSession
 
PROPERTIES_INDEX - Static variable in class org.activemq.message.ActiveMQMessage
 
PropertiesConfigLoader - Class in org.activemq.security.jassjacc
Parses a Properties object into a set of BrokerSecurityConfig and DestinationSecurityConfig objects that can be used to secure the ActiveMQ broker.
PropertiesConfigLoader(String, Properties) - Constructor for class org.activemq.security.jassjacc.PropertiesConfigLoader
 
PROPERTY_STORE_DIRECTORY - Static variable in class org.activemq.broker.impl.DefaultBroker
 
propertyExists(String) - Method in class org.activemq.message.ActiveMQMessage
Indicates whether a property value exists.
PropertyExpression - Class in org.activemq.filter
Represents a property expression
PropertyExpression(String) - Constructor for class org.activemq.filter.PropertyExpression
 
PRORITY - Static variable in interface org.activemq.transport.stomp.Stomp.Headers.Message
 
PRORITY - Static variable in interface org.activemq.transport.stomp.Stomp.Headers.Send
 
PROVIDER_MAJOR_VERSION - Static variable in class org.activemq.ActiveMQConnectionMetaData
 
PROVIDER_MINOR_VERSION - Static variable in class org.activemq.ActiveMQConnectionMetaData
 
PROVIDER_VERSION - Static variable in class org.activemq.ActiveMQConnectionMetaData
 
proxy(MessageStore) - Method in class org.activemq.store.vm.VMTransactionStore
 
proxy(TopicMessageStore) - Method in class org.activemq.store.vm.VMTransactionStore
 
ProxyMessageContainerManager - Class in org.activemq.service.impl
A Proxy implementation of MessageContainerManager which delegates to some other implementation which is useful for writing Facade implementations
ProxyMessageContainerManager() - Constructor for class org.activemq.service.impl.ProxyMessageContainerManager
 
ProxyMessageContainerManager(MessageContainerManager) - Constructor for class org.activemq.service.impl.ProxyMessageContainerManager
 
ProxyMessageStore - Class in org.activemq.store
A simple proxy that delegates to another MessageStore.
ProxyMessageStore(MessageStore) - Constructor for class org.activemq.store.ProxyMessageStore
 
ProxyTopicMessageStore - Class in org.activemq.store
A simple proxy that delegates to another MessageStore.
ProxyTopicMessageStore(TopicMessageStore) - Constructor for class org.activemq.store.ProxyTopicMessageStore
 
publish(Message) - Method in class org.activemq.ActiveMQTopicPublisher
Publishes a message to the topic.
publish(Message, int, int, long) - Method in class org.activemq.ActiveMQTopicPublisher
Publishes a message to the topic, specifying delivery mode, priority, and time to live.
publish(Topic, Message) - Method in class org.activemq.ActiveMQTopicPublisher
Publishes a message to a topic for an unidentified message producer.
publish(Topic, Message, int, int, long) - Method in class org.activemq.ActiveMQTopicPublisher
Publishes a message to a topic for an unidentified message producer, specifying delivery mode, priority and time to live.
publish(Message) - Method in class org.activemq.pool.PooledTopicPublisher
 
publish(Message, int, int, long) - Method in class org.activemq.pool.PooledTopicPublisher
 
publish(Topic, Message) - Method in class org.activemq.pool.PooledTopicPublisher
 
publish(Topic, Message, int, int, long) - Method in class org.activemq.pool.PooledTopicPublisher
 
pushConnection(Connection) - Static method in class org.activemq.store.jdbc.TransactionContext
Sets the current transaction, possibly including nesting
put(ActiveMQDestination, Object) - Method in class org.activemq.filter.DestinationMap
add destination to the map
put(String, ActiveMQMessage) - Method in class org.activemq.io.util.MemoryBoundedMessageCache
Puts a message into the cache.
put(String, Object) - Method in class org.activemq.message.ActiveMQMapMessage
 
put(String, ActiveMQMessage) - Method in interface org.activemq.store.cache.MessageCache
Puts a message into the cache.
put(String, ActiveMQMessage) - Method in class org.activemq.store.cache.SimpleMessageCache
Puts a message into the cache.

Q

queueConsumerMap - Variable in class org.activemq.transport.NetworkChannel
 
QueueList - Interface in org.activemq.service
Represents a Queue with List like semantics, allowing addition and removal at any point in the queue.
QueueListEntry - Interface in org.activemq.service
Represents an entry in a linked list
QueueListSupport - Class in org.activemq.service.impl
A base class which is useful for implementation inheritence when implementing a persistent QueueList
QueueListSupport() - Constructor for class org.activemq.service.impl.QueueListSupport
 
QueueListSupport.Header - Class in org.activemq.service.impl
 
QueueListSupport.Header() - Constructor for class org.activemq.service.impl.QueueListSupport.Header
 
QueueListSupport.Node - Class in org.activemq.service.impl
 
QueueListSupport.Node() - Constructor for class org.activemq.service.impl.QueueListSupport.Node
 
QueueMessageContainer - Interface in org.activemq.service
A Queue based MessageContainer
QueueMessageContainerManager - Interface in org.activemq.service
A manager of MessageContainer instances
quickClose - Variable in class org.activemq.ActiveMQConnectionFactory
 

R

randomizeURIs(List) - Method in class org.activemq.transport.composite.CompositeTransportChannelFactory
 
randomizeURIs(List) - Method in class org.activemq.transport.reliable.ReliableTransportChannelFactory
 
RangeStatisticImpl - Class in org.activemq.management
A range statistic implementation
RangeStatisticImpl(String, String, String) - Constructor for class org.activemq.management.RangeStatisticImpl
 
read() - Method in class org.activemq.io.util.WireByteArrayInputStream
Reads the next byte of data from this input stream.
read(byte[], int, int) - Method in class org.activemq.io.util.WireByteArrayInputStream
Reads up to len bytes of data into an array of bytes from this input stream.
read(DataInput) - Static method in class org.activemq.message.ActiveMQXid
Reads the Xid from a stream
read() - Method in class org.activemq.streams.JMSInputStream
Read the next byte from this stream.
read(byte[]) - Method in class org.activemq.streams.JMSInputStream
Read data from this input stream into the given byte array starting at offset 0 for b.length bytes.
read(byte[], int, int) - Method in class org.activemq.streams.JMSInputStream
Read data from this input stream into the given byte array starting at offset 'off' for 'len' bytes.
readBody(DataInput) - Method in class org.activemq.message.ActiveMQMapMessage
 
readBody(DataInput) - Method in class org.activemq.message.ActiveMQMessage
Used to help build the body from an input stream
readBody(DataInput) - Method in class org.activemq.message.ActiveMQObjectMessage
Used to help build the body from an input stream
readBody(DataInput) - Method in class org.activemq.message.ActiveMQTextMessage
Used to help build the body from an input stream
readBody(DataInput) - Method in interface org.activemq.message.BodyPacket
 
readBody(DataInput) - Method in class org.activemq.message.CachedValue
 
readBody(DataInput) - Method in class org.activemq.message.MessageAck
 
readBoolean() - Method in class org.activemq.message.ActiveMQBytesMessage
Reads a boolean from the bytes message stream.
readBoolean() - Method in class org.activemq.message.ActiveMQStreamMessage
Reads a boolean from the stream message.
readByte() - Method in class org.activemq.message.ActiveMQBytesMessage
Reads a signed 8-bit value from the bytes message stream.
readByte() - Method in class org.activemq.message.ActiveMQStreamMessage
Reads a byte value from the stream message.
readBytes(byte[]) - Method in class org.activemq.message.ActiveMQBytesMessage
Reads a byte array from the bytes message stream.
readBytes(byte[], int) - Method in class org.activemq.message.ActiveMQBytesMessage
Reads a portion of the bytes message stream.
readBytes(byte[]) - Method in class org.activemq.message.ActiveMQStreamMessage
Reads a byte array field from the stream message into the specified byte[] object (the read buffer).
readBytes(DataInput) - Static method in class org.activemq.message.ActiveMQXid
 
readChar() - Method in class org.activemq.message.ActiveMQBytesMessage
Reads a Unicode character value from the bytes message stream.
readChar() - Method in class org.activemq.message.ActiveMQStreamMessage
Reads a Unicode character value from the stream message.
readChar() - Method in class org.activemq.selector.SimpleCharStream
 
readDestination(DataInput) - Method in class org.activemq.io.impl.AbstractPacketMarshaller
Reads a destination from the input stream
readDouble() - Method in class org.activemq.message.ActiveMQBytesMessage
Reads a double from the bytes message stream.
readDouble() - Method in class org.activemq.message.ActiveMQStreamMessage
Reads a double from the stream message.
readElement(XMLStreamReader, ActiveMQTextMessage) - Method in class org.activemq.transport.jabber.JabberWireFormat
 
readExternal(ObjectInput) - Method in class org.activemq.advisories.TempDestinationAdvisoryEvent
read from a stream
readExternal(ObjectInput) - Method in class org.activemq.message.ActiveMQXid
 
readExternal(ObjectInput) - Method in class org.activemq.message.PacketFacade
 
readExternal(ObjectInput) - Method in class org.activemq.service.impl.MessageEntry
 
readExternal(ObjectInput) - Method in class org.activemq.service.SubscriberEntry
 
readFloat() - Method in class org.activemq.message.ActiveMQBytesMessage
Reads a float from the bytes message stream.
readFloat() - Method in class org.activemq.message.ActiveMQStreamMessage
Reads a float from the stream message.
readFromStream(DataInput) - Static method in class org.activemq.message.ActiveMQDestination
Read an ActiveMQDestination from a Stream
readFromStream(DataInput) - Method in class org.activemq.util.BitArray
read the bits from an input stream
readInt() - Method in class org.activemq.message.ActiveMQBytesMessage
Reads a signed 32-bit integer from the bytes message stream.
readInt() - Method in class org.activemq.message.ActiveMQStreamMessage
Reads a 32-bit integer from the stream message.
readLong() - Method in class org.activemq.message.ActiveMQBytesMessage
Reads a signed 64-bit integer from the bytes message stream.
readLong() - Method in class org.activemq.message.ActiveMQStreamMessage
Reads a 64-bit integer from the stream message.
readMapProperties(DataInput) - Method in class org.activemq.message.ActiveMQMessage
 
readMessage(XMLStreamReader) - Method in class org.activemq.transport.jabber.JabberWireFormat
 
readMutex - Variable in class org.activemq.io.impl.DefaultWireFormat
 
readNullableUTF(ObjectInput) - Static method in class org.activemq.service.SubscriberEntry
 
readObject(DataInput) - Method in class org.activemq.io.impl.AbstractPacketReader
;
readObject() - Method in class org.activemq.message.ActiveMQStreamMessage
Reads an object from the stream message.
readObject(byte[]) - Static method in class org.activemq.util.SerializationHelper
Read an Object from a byte array
readObject(InputStream) - Static method in class org.activemq.util.SerializationHelper
read an object from an InputStream
ReadOnlyContext - Class in org.activemq.jndi
A read-only Context

This version assumes it and all its subcontext are read-only and any attempt to modify (e.g.

ReadOnlyContext() - Constructor for class org.activemq.jndi.ReadOnlyContext
 
ReadOnlyContext(Hashtable) - Constructor for class org.activemq.jndi.ReadOnlyContext
 
ReadOnlyContext(Hashtable, Map) - Constructor for class org.activemq.jndi.ReadOnlyContext
 
ReadOnlyContext(Hashtable, Map, String) - Constructor for class org.activemq.jndi.ReadOnlyContext
 
ReadOnlyContext(ReadOnlyContext, Hashtable) - Constructor for class org.activemq.jndi.ReadOnlyContext
 
ReadOnlyContext(ReadOnlyContext, Hashtable, String) - Constructor for class org.activemq.jndi.ReadOnlyContext
 
readOnlyMessage - Variable in class org.activemq.message.ActiveMQMessage
readOnlyMessage denotes if the message is read only
readPacket(String, DatagramPacket) - Method in class org.activemq.io.AbstractWireFormat
Read a packet from a Datagram packet from the given channelID.
readPacket(DataInput) - Method in class org.activemq.io.AbstractWireFormat
 
readPacket(DataInput, PacketReader) - Method in class org.activemq.io.impl.AbstractDefaultWireFormat
 
readPacket(int, DataInput) - Method in class org.activemq.io.impl.AbstractDefaultWireFormat
 
readPacket(DataInput, PacketReader) - Method in class org.activemq.io.impl.DefaultWireFormat
 
readPacket(DataInput, PacketReader) - Method in class org.activemq.io.impl.StatelessDefaultWireFormat
 
readPacket(Packet) - Method in class org.activemq.io.impl.StatelessDefaultWireFormat
 
readPacket(DataInput) - Method in interface org.activemq.io.WireFormat
Reads a packet from the given input stream
readPacket(int, DataInput) - Method in interface org.activemq.io.WireFormat
A helper method for working with sockets where the first byte is read first, then the rest of the message is read.
readPacket(String, DatagramPacket) - Method in interface org.activemq.io.WireFormat
Read a packet from a Datagram packet from the given channelID.
readPacket(RecordLocation) - Method in class org.activemq.store.journal.JournalPersistenceAdapter
 
readPacket(int, DataInput) - Method in class org.activemq.transport.jabber.JabberWireFormat
 
readPacket(XMLStreamReader, List) - Method in class org.activemq.transport.jabber.JabberWireFormat
Reads a packet from the XML stream
readPacket(DataInput) - Method in class org.activemq.transport.stomp.StompWireFormat
 
readPacket(int, DataInput) - Method in class org.activemq.transport.stomp.StompWireFormat
A helper method for working with sockets where the first byte is read first, then the rest of the message is read.
readPacket(String, DatagramPacket) - Method in class org.activemq.transport.stomp.StompWireFormat
Read a packet from a Datagram packet from the given channelID.
readPacketFromByteArray(byte[]) - Method in class org.activemq.io.impl.AbstractPacketReader
Deserailizes a Packet from a byte array
readPacketFromByteArray(byte[]) - Method in interface org.activemq.io.impl.PacketReader
Deserailizes a Packet from a byte array
readShort() - Method in class org.activemq.message.ActiveMQBytesMessage
Reads a signed 16-bit number from the bytes message stream.
readShort() - Method in class org.activemq.message.ActiveMQStreamMessage
Reads a 16-bit integer from the stream message.
readState(DataInput) - Method in class org.activemq.message.ActiveMQXid
 
readString() - Method in class org.activemq.message.ActiveMQStreamMessage
Reads a String from the stream message.
readText(DataInput) - Method in class org.activemq.message.ActiveMQTextMessage
read the text as UTF-8
readUnsignedByte() - Method in class org.activemq.message.ActiveMQBytesMessage
Reads an unsigned 8-bit number from the bytes message stream.
readUnsignedShort() - Method in class org.activemq.message.ActiveMQBytesMessage
Reads an unsigned 16-bit number from the bytes message stream.
readUTF(DataInput) - Method in class org.activemq.io.impl.AbstractPacketReader
pointless method - but mirrors writer
readUTF() - Method in class org.activemq.message.ActiveMQBytesMessage
Reads a string that has been encoded using a modified UTF-8 format from the bytes message stream.
readWireFormat() - Method in class org.activemq.transport.stomp.StompTransportChannel
 
readWireFormat() - Method in class org.activemq.transport.tcp.TcpTransportChannel
 
readXMLAsText(XMLStreamReader) - Method in class org.activemq.transport.jabber.JabberWireFormat
 
rebind(Name, Object) - Method in class org.activemq.jndi.ReadOnlyContext
 
rebind(String, Object) - Method in class org.activemq.jndi.ReadOnlyContext
 
Receipt - Class in org.activemq.message
Sent in receipt of a Packet
Receipt() - Constructor for class org.activemq.message.Receipt
 
receipt - Variable in class org.activemq.message.ReceiptHolder
 
RECEIPT - Static variable in interface org.activemq.transport.stomp.Stomp.Responses
 
RECEIPT_ID - Static variable in interface org.activemq.transport.stomp.Stomp.Headers.Receipt
 
RECEIPT_INFO - Static variable in interface org.activemq.message.Packet
Recipt message
RECEIPT_REQUESTED - Static variable in interface org.activemq.transport.stomp.Stomp.Headers
 
RECEIPT_REQUIRED_INDEX - Static variable in class org.activemq.message.AbstractPacket
Message flag indexes (used for writing/reading to/from a Stream
ReceiptHolder - Class in org.activemq.message
ReceiptHolder is a utility class used for waiting for receipts from Packets sent to the broker
ReceiptHolder() - Constructor for class org.activemq.message.ReceiptHolder
Construct a receipt holder
receiptReader - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
ReceiptReader - Class in org.activemq.io.impl
Reads a ConsumerInfo object from a Stream
ReceiptReader() - Constructor for class org.activemq.io.impl.ReceiptReader
 
receiptWriter - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
ReceiptWriter - Class in org.activemq.io.impl
Writes a ConsumerInfo object to a Stream
ReceiptWriter() - Constructor for class org.activemq.io.impl.ReceiptWriter
 
receive(long) - Method in class org.activemq.ActiveMQConnectionConsumer
Receives the next message that arrives within the specified timeout interval.
receive() - Method in class org.activemq.ActiveMQMessageConsumer
Receives the next message produced for this message consumer.
receive(long) - Method in class org.activemq.ActiveMQMessageConsumer
Receives the next message that arrives within the specified timeout interval.
receiveNoWait() - Method in class org.activemq.ActiveMQMessageConsumer
Receives the next message if one is immediately available.
RECONNECTED - Static variable in class org.activemq.transport.TransportStatusEvent
The channel has successfully reconnected after a disconnect
reconnectSleepTime - Variable in class org.activemq.transport.NetworkChannel
 
recover() - Method in class org.activemq.ActiveMQQueueSession
 
recover() - Method in class org.activemq.ActiveMQSession
Stops message delivery in this session, and restarts message delivery with the oldest unacknowledged message.
recover() - Method in class org.activemq.ActiveMQTopicSession
 
RECOVER - Static variable in interface org.activemq.message.TransactionType
Recover a transaction
recover() - Method in class org.activemq.pool.PooledSession
 
recover(Transaction) - Method in class org.activemq.service.impl.TransactionManagerImpl
 
recover(Transaction) - Method in class org.activemq.service.TransactionManager
Called on restart when recovering prepared transactions to reload a transaction from persistent store
recover(RecoveryListener) - Method in class org.activemq.store.cache.CacheMessageStore
Replays the checkpointStore first as those messages are the oldest ones, then messages are replayed from the transaction log and then the cache is updated.
recover(RecoveryListener) - Method in class org.activemq.store.jdbc.JDBCMessageStore
 
recover(RecoveryListener) - Method in class org.activemq.store.journal.JournalMessageStore
Replays the checkpointStore first as those messages are the oldest ones, then messages are replayed from the transaction log and then the cache is updated.
recover(TransactionStore.RecoveryListener) - Method in class org.activemq.store.journal.JournalTransactionStore
 
recover(RecoveryListener) - Method in interface org.activemq.store.MessageStore
Recover any messages to be delivered.
recover(RecoveryListener) - Method in class org.activemq.store.ProxyMessageStore
 
recover(RecoveryListener) - Method in class org.activemq.store.ProxyTopicMessageStore
 
recover(TransactionStore.RecoveryListener) - Method in interface org.activemq.store.TransactionStore
 
recover(ActiveMQXid, ActiveMQMessage[], MessageAck[]) - Method in interface org.activemq.store.TransactionStore.RecoveryListener
 
recover(RecoveryListener) - Method in class org.activemq.store.vm.VMMessageStore
 
recover(TransactionStore.RecoveryListener) - Method in class org.activemq.store.vm.VMTransactionStore
 
recover(int) - Method in class org.activemq.TransactionContext
 
recoverMessage(MessageIdentity) - Method in interface org.activemq.store.RecoveryListener
 
recoverMessageToBeDelivered(MessageIdentity) - Method in class org.activemq.service.impl.DurableQueueMessageContainer
 
recoverMessageToBeDelivered(MessageIdentity) - Method in interface org.activemq.service.QueueMessageContainer
Invoked during the recovery to add the given message to the end of the messages to be delivered.
recoverSubscription(Subscription) - Method in class org.activemq.service.impl.DurableTopicMessageContainer
 
recoverSubscription(Subscription) - Method in interface org.activemq.service.TopicMessageContainer
A durable subscription has started so recovery any messages that are required.
recoverSubscription(String, MessageIdentity, RecoveryListener) - Method in class org.activemq.store.cache.CacheTopicMessageStore
 
recoverSubscription(String, MessageIdentity, RecoveryListener) - Method in class org.activemq.store.jdbc.JDBCTopicMessageStore
 
recoverSubscription(String, MessageIdentity, RecoveryListener) - Method in class org.activemq.store.journal.JournalTopicMessageStore
 
recoverSubscription(String, MessageIdentity, RecoveryListener) - Method in class org.activemq.store.ProxyTopicMessageStore
 
recoverSubscription(String, MessageIdentity, RecoveryListener) - Method in interface org.activemq.store.TopicMessageStore
For the new subcription find the last acknowledged message ID and then find any new messages since then and dispatch them to the subscription.
recoverSubscription(String, MessageIdentity, RecoveryListener) - Method in class org.activemq.store.vm.VMTopicMessageStore
 
recoverSubscriptions(Subscription) - Method in class org.activemq.service.impl.DurableTopicMessageContainerManager
This method is called when a new durable subscription is started and so we need to go through each matching message container and dispatch any matching messages that may be outstanding
RecoveryListener - Interface in org.activemq.store
 
redeliver(DurableMessagePointer) - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageContainer
 
redeliver(List) - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageContainer
 
redeliver(ActiveMQMessage) - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
re-enqueue a message for dispatching
redeliver(List) - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
 
REDELIVERED - Static variable in interface org.activemq.transport.stomp.Stomp.Headers.Message
 
REDELIVERED_INDEX - Static variable in class org.activemq.message.ActiveMQMessage
 
redeliverUnacknowledgedMessages() - Method in class org.activemq.ActiveMQSession
 
redeliverUnacknowledgedMessages(boolean) - Method in class org.activemq.ActiveMQSession
 
RedeliveryPolicy - Class in org.activemq.service
Represents the redelivery policy which is used when a rollback() occurs (either JMS or XA).
RedeliveryPolicy() - Constructor for class org.activemq.service.RedeliveryPolicy
 
ReflectionSupport - Class in org.activemq.util
 
ReflectionSupport() - Constructor for class org.activemq.util.ReflectionSupport
 
register(MessageContainerManager) - Method in interface org.activemq.service.Dispatcher
Register the MessageContainerManager for the Dispatcher
register(MessageContainerManager) - Method in class org.activemq.service.impl.DispatcherImpl
Register the MessageContainerManager for the Dispatcher
register(MessageContainerManager) - Method in class org.activemq.service.impl.DispatchWorker
Register the MessageContainerManager for the Dispatcher
registerBeanDefinitions(Document, Resource) - Method in class org.activemq.spring.ActiveMQBeanDefinitionReader
 
registerBroker(String, BrokerConnector) - Static method in class org.activemq.ActiveMQConnectionFactory
 
registerClient(BrokerClient, ConnectionInfo) - Method in interface org.activemq.broker.BrokerConnector
Register a Broker Client
registerClient(BrokerClient, ConnectionInfo) - Method in class org.activemq.broker.impl.BrokerConnectorImpl
Register a Broker Client
registerConnection(BrokerClient, ConnectionInfo) - Method in interface org.activemq.broker.BrokerContainer
registers a new Connection
registerConnection(BrokerClient, ConnectionInfo) - Method in class org.activemq.broker.impl.BrokerContainerImpl
registers a new Connection
registerConnector(String, BrokerConnector) - Method in class org.activemq.broker.BrokerContext
 
registerContainer(String, BrokerContainer) - Method in class org.activemq.broker.BrokerContext
 
registerMessageConsumer(BrokerClient, ConsumerInfo) - Method in interface org.activemq.broker.BrokerConnector
Registers a MessageConsumer
registerMessageConsumer(BrokerClient, ConsumerInfo) - Method in interface org.activemq.broker.BrokerContainer
Registers a MessageConsumer
registerMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.activemq.broker.impl.BrokerConnectorImpl
Registers a MessageConsumer
registerMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.activemq.broker.impl.BrokerContainerImpl
Registers a MessageConsumer
registerMessageInterest(MessageIdentity) - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
 
registerMessageInterest(MessageIdentity) - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
 
registerMessageInterest(MessageIdentity) - Method in class org.activemq.service.impl.DurableQueueMessageContainer
Does nothing since when we receive an acknowledgement on a queue we can delete the message
registerMessageInterest(MessageIdentity) - Method in class org.activemq.service.impl.DurableTopicMessageContainer
 
registerMessageInterest(MessageIdentity) - Method in interface org.activemq.service.MessageContainer
Register that a consumer will be interested in this message
registerMessageProducer(BrokerClient, ProducerInfo) - Method in interface org.activemq.broker.BrokerConnector
Registers a MessageProducer
registerMessageProducer(BrokerClient, ProducerInfo) - Method in interface org.activemq.broker.BrokerContainer
Registers a MessageProducer
registerMessageProducer(BrokerClient, ProducerInfo) - Method in class org.activemq.broker.impl.BrokerConnectorImpl
Registers a MessageProducer
registerMessageProducer(BrokerClient, ProducerInfo) - Method in class org.activemq.broker.impl.BrokerContainerImpl
Registers a MessageProducer
registerRemoteClientID(String) - Method in interface org.activemq.broker.BrokerContainer
register a remote clientID
registerRemoteClientID(String) - Method in class org.activemq.broker.impl.BrokerContainerImpl
register a remote clientID
registerService(String, Map) - Method in interface org.activemq.transport.DiscoveryAgent
register a service
registerService(String, Map) - Method in class org.activemq.transport.multicast.MulticastDiscoveryAgent
Register a service for other discover nodes
registerSession(BrokerClient, SessionInfo) - Method in interface org.activemq.broker.BrokerConnector
Register a client-side Session (used for Monitoring)
registerSession(BrokerClient, SessionInfo) - Method in interface org.activemq.broker.BrokerContainer
Register a client-side Session (used for Monitoring)
registerSession(BrokerClient, SessionInfo) - Method in class org.activemq.broker.impl.BrokerConnectorImpl
Register a client-side Session (used for Monitoring)
registerSession(BrokerClient, SessionInfo) - Method in class org.activemq.broker.impl.BrokerContainerImpl
Register a client-side Session (used for Monitoring)
registerTransactionId(String, String) - Method in class org.activemq.transport.stomp.StompWireFormat
 
registerTransportStreams(DataOutputStream, DataInputStream) - Method in class org.activemq.io.AbstractWireFormat
some transports may register their streams (e.g.
registerTransportStreams(DataOutputStream, DataInputStream) - Method in interface org.activemq.io.WireFormat
some transports may register their streams (e.g.
registerTransportStreams(DataOutputStream, DataInputStream) - Method in class org.activemq.transport.stomp.StompWireFormat
some transports may register their streams (e.g.
ReInit(InputStream) - Method in class org.activemq.selector.SelectorParser
 
ReInit(Reader) - Method in class org.activemq.selector.SelectorParser
 
ReInit(SelectorParserTokenManager) - Method in class org.activemq.selector.SelectorParser
 
ReInit(SimpleCharStream) - Method in class org.activemq.selector.SelectorParserTokenManager
 
ReInit(SimpleCharStream, int) - Method in class org.activemq.selector.SelectorParserTokenManager
 
ReInit(Reader, int, int, int) - Method in class org.activemq.selector.SimpleCharStream
 
ReInit(Reader, int, int) - Method in class org.activemq.selector.SimpleCharStream
 
ReInit(Reader) - Method in class org.activemq.selector.SimpleCharStream
 
ReInit(InputStream, int, int, int) - Method in class org.activemq.selector.SimpleCharStream
 
ReInit(InputStream) - Method in class org.activemq.selector.SimpleCharStream
 
ReInit(InputStream, int, int) - Method in class org.activemq.selector.SimpleCharStream
 
ReliableTransportChannel - Class in org.activemq.transport.reliable
A Compsite implementation of a TransportChannel
ReliableTransportChannel(WireFormat) - Constructor for class org.activemq.transport.reliable.ReliableTransportChannel
Construct this transport
ReliableTransportChannel(WireFormat, List) - Constructor for class org.activemq.transport.reliable.ReliableTransportChannel
Construct this transport
ReliableTransportChannelFactory - Class in org.activemq.transport.reliable
A Reliable implementation of a TransportChannelFactory
ReliableTransportChannelFactory() - Constructor for class org.activemq.transport.reliable.ReliableTransportChannelFactory
 
remote - Variable in class org.activemq.transport.peer.PeerTransportChannel
 
remoteBrokerName - Variable in class org.activemq.transport.NetworkChannel
 
remoteClusterName - Variable in class org.activemq.transport.NetworkChannel
 
remoteConnection - Variable in class org.activemq.transport.NetworkChannel
 
RemoteNetworkChannel - Class in org.activemq.transport
Represents a Boondocks broker's connection with a single remote broker which bridges the two brokers to form a network.
RemoteNetworkChannel(PooledExecutor) - Constructor for class org.activemq.transport.RemoteNetworkChannel
Default Constructor
RemoteNetworkChannel(NetworkConnector, BrokerContainer, String) - Constructor for class org.activemq.transport.RemoteNetworkChannel
Constructor
RemoteNetworkConnector - Class in org.activemq.transport
Represents a connector to one or more remote brokers.
RemoteNetworkConnector(BrokerContainer) - Constructor for class org.activemq.transport.RemoteNetworkConnector
RemoteNetworkConnector
remotePassword - Variable in class org.activemq.transport.NetworkChannel
 
remotePassword - Variable in class org.activemq.transport.peer.PeerTransportChannel
 
RemoteTransportChannel - Class in org.activemq.transport.remote
A RemoteTransportChannel creates an embedded broker that creates a remote connection to another broker.
RemoteTransportChannel(WireFormat, String) - Constructor for class org.activemq.transport.remote.RemoteTransportChannel
Construct a RemoteTransportChannel
RemoteTransportChannelFactory - Class in org.activemq.transport.remote
Creates a remote based transport.
RemoteTransportChannelFactory() - Constructor for class org.activemq.transport.remote.RemoteTransportChannelFactory
 
remoteUserName - Variable in class org.activemq.transport.NetworkChannel
 
remoteUserName - Variable in class org.activemq.transport.peer.PeerTransportChannel
 
remove(ActiveMQDestination, Object) - Method in class org.activemq.filter.DestinationMap
Removes the value from the associated destination
remove(String[], int, Object) - Method in class org.activemq.filter.DestinationMapNode
 
remove(String) - Method in class org.activemq.io.util.MemoryBoundedMessageCache
Remvoes a message from the cache.
remove(MemoryBoundedObject) - Method in class org.activemq.io.util.MemoryBoundedObjectManager
 
remove(MemoryManageable) - Method in class org.activemq.io.util.MemoryBoundedPrioritizedQueue
Remove a packet from the queue
remove(Object) - Method in class org.activemq.io.util.MemoryBoundedPrioritizedQueue
Remove a MemoryManageable by it's id
remove(MemoryManageable) - Method in class org.activemq.io.util.MemoryBoundedQueue
Remove a packet from the queue
remove(Object) - Method in class org.activemq.io.util.MemoryBoundedQueue
Remove a MemoryManageable by it's id
remove(MemoryBoundedQueue) - Method in class org.activemq.io.util.MemoryBoundedQueueManager
 
remove(Object) - Method in class org.activemq.service.impl.DefaultQueueList
 
remove(int) - Method in class org.activemq.service.impl.DefaultQueueList
 
remove(QueueListEntry) - Method in class org.activemq.service.impl.DefaultQueueList
 
remove(int) - Method in class org.activemq.service.impl.QueueListSupport
 
remove(QueueListEntry) - Method in class org.activemq.service.impl.QueueListSupport
 
remove(Object) - Method in interface org.activemq.service.QueueList
Removes the first occurrence of the specified element in this list.
remove(int) - Method in interface org.activemq.service.QueueList
Removes the element at the specified position in this list.
remove(QueueListEntry) - Method in interface org.activemq.service.QueueList
Remove a DefaultQueueListEntry
remove(String) - Method in interface org.activemq.store.cache.MessageCache
Remvoes a message from the cache.
remove(String) - Method in class org.activemq.store.cache.SimpleMessageCache
Remvoes a message from the cache.
removeActiveSubscription(BrokerClient, Subscription) - Method in interface org.activemq.service.Dispatcher
remove an active subscription
removeActiveSubscription(BrokerClient, Subscription) - Method in class org.activemq.service.impl.DispatcherImpl
remove an active subscription
removeActiveSubscription(BrokerClient, Subscription) - Method in class org.activemq.service.impl.DispatchWorker
remove an active subscription
removeAll(ActiveMQDestination) - Method in class org.activemq.filter.DestinationMap
remove all destinations associated with a key
removeAll(String[], int) - Method in class org.activemq.filter.DestinationMapNode
 
removeAllAckedMessages() - Method in class org.activemq.service.boundedvm.DurableQueueSubscription
Add an acked message.
removeAllAckedMessages() - Method in class org.activemq.service.boundedvm.TransientQueueSubscription
Add an acked message.
removeAllMessages() - Method in class org.activemq.store.cache.CacheMessageStore
 
removeAllMessages() - Method in class org.activemq.store.jdbc.JDBCMessageStore
 
removeAllMessages() - Method in class org.activemq.store.journal.JournalMessageStore
 
removeAllMessages() - Method in interface org.activemq.store.MessageStore
Removes all the messages from the message store.
removeAllMessages() - Method in class org.activemq.store.ProxyMessageStore
 
removeAllMessages() - Method in class org.activemq.store.ProxyTopicMessageStore
 
removeAllMessages() - Method in class org.activemq.store.vm.VMMessageStore
 
removeCapacityEventListener(CapacityMonitorEventListener) - Method in class org.activemq.capacity.BasicCapacityMonitor
Remove a CapacityMonitorEventListener
removeCapacityEventListener(CapacityMonitorEventListener) - Method in interface org.activemq.capacity.CapacityMonitor
Remove a CapacityMonitorEventListener
removeCapacityEventListener(CapacityMonitorEventListener) - Method in class org.activemq.capacity.DelegateCapacityMonitor
Remove a CapacityEventListener
removeChannel(String, Map) - Method in class org.activemq.transport.DiscoveryNetworkConnector
 
removeClient(BrokerClient, ConnectionInfo) - Method in interface org.activemq.broker.Broker
A hint to the broker that an BrokerClient has stopped This enables the broker to clean-up any outstanding processing that may be outstanding
removeClient(TransportChannel) - Method in class org.activemq.broker.impl.BrokerConnectorImpl
 
removeClient(BrokerClient, ConnectionInfo) - Method in class org.activemq.broker.impl.DefaultBroker
 
removeClient(TransportChannel) - Method in interface org.activemq.transport.TransportChannelListener
Called when a channel has been closed and removed from a server
removeClient(TransportChannel) - Method in class org.activemq.transport.TransportServerChannelSupport
remove a channel
removeConnection(ActiveMQConnection) - Method in class org.activemq.management.JMSStatsImpl
 
removeConnectionConsumer(ActiveMQConnectionConsumer) - Method in class org.activemq.ActiveMQConnection
Remove a ConnectionConsumer
removeConnector(BrokerConnector) - Method in interface org.activemq.broker.BrokerContainer
Called when a connector is removed to this container
removeConnector(BrokerConnector) - Method in class org.activemq.broker.impl.BrokerContainerImpl
 
removeConsumer(ActiveMQMessageConsumer) - Method in class org.activemq.ActiveMQSession
 
removeConsumer(ConsumerInfo) - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageContainer
Remove a consumer
removeConsumer(ConsumerInfo) - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
Remove a consumer
removeConsumer(ConsumerInfo) - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
Remove a consumer
removeConsumerInfoListener(ConsumerInfoListener) - Method in interface org.activemq.broker.Broker
Remove a ConsumerInfoListener from the Broker
removeConsumerInfoListener(ConsumerInfoListener) - Method in class org.activemq.broker.impl.DefaultBroker
Remove a ConsumerInfoListener from the Broker
removeDiscoveryListener(DiscoveryListener) - Method in interface org.activemq.transport.DiscoveryAgent
remove a discovery listener
removeDiscoveryListener(DiscoveryListener) - Method in class org.activemq.transport.DiscoveryAgentSupport
remove a discovery listener
removeEldestEntry(Map.Entry) - Method in class org.activemq.util.LRUCache
 
removeEventListner(String, MultiExpressionEvaluator.ExpressionListener) - Method in class org.activemq.filter.MultiExpressionEvaluator
Removes an ExpressionListener from receiving the results of a given evaluation.
removeExpiredMessages() - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageContainer
 
removeExpiredMessages() - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
 
removeFirst() - Method in class org.activemq.service.impl.DefaultQueueList
remove the first object from the list
removeFirst() - Method in class org.activemq.service.impl.QueueListSupport
 
removeFirst() - Method in interface org.activemq.service.QueueList
Removes and returns the first element from this list.
removeFromEnvironment(String) - Method in class org.activemq.jndi.ReadOnlyContext
 
removeLast() - Method in class org.activemq.service.impl.DefaultQueueList
remove the last object
removeLast() - Method in class org.activemq.service.impl.QueueListSupport
 
removeLast() - Method in interface org.activemq.service.QueueList
Removes and returns the last element from this list.
removeListener(ConnectionAdvisoryEventListener) - Method in class org.activemq.advisories.ConnectionAdvisor
Remove a listener
removeListener(ConsumerAdvisoryEventListener) - Method in class org.activemq.advisories.ConsumerAdvisor
Remove a listener
removeListener(ProducerAdvisoryEventListener) - Method in class org.activemq.advisories.ProducerAdvisor
Remove a listener
removeListener(TempDestinationAdvisoryEventListener) - Method in class org.activemq.advisories.TempDestinationAdvisor
Remove a listener
removeMessage(MessageAck) - Method in class org.activemq.store.cache.CacheMessageStore
Remove the meessage to the long term store and remove it from the cache.
removeMessage(MessageAck) - Method in class org.activemq.store.jdbc.JDBCMessageStore
 
removeMessage(MessageAck) - Method in class org.activemq.store.journal.JournalMessageStore
 
removeMessage(JournalMessageStore, MessageAck, RecordLocation) - Method in class org.activemq.store.journal.JournalTransactionStore
 
removeMessage(MessageAck) - Method in interface org.activemq.store.MessageStore
Removes a message from the message store.
removeMessage(MessageAck) - Method in class org.activemq.store.ProxyMessageStore
 
removeMessage(MessageAck) - Method in class org.activemq.store.ProxyTopicMessageStore
 
removeMessage(MessageAck) - Method in class org.activemq.store.vm.VMMessageStore
 
removeMessage(MessageIdentity) - Method in class org.activemq.store.vm.VMMessageStore
 
removeMessageConsumer(BrokerClient, ConsumerInfo) - Method in interface org.activemq.broker.Broker
remove an active message consumer
removeMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.activemq.broker.impl.DefaultBroker
remove an active message consumer
removeMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageManager
 
removeMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageManager
 
removeMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageManager
 
removeMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.activemq.service.impl.DurableQueueMessageContainerManager
 
removeMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.activemq.service.impl.DurableTopicMessageContainerManager
 
removeMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.activemq.service.impl.ProxyMessageContainerManager
 
removeMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.activemq.service.impl.TransientTopicMessageContainerManager
 
removeMessageConsumer(BrokerClient, ConsumerInfo) - Method in interface org.activemq.service.MessageContainerManager
 
removeMessageDispatcher(ActiveMQMessageDispatcher) - Method in class org.activemq.ActiveMQConnection
Remove a Message dispatcher
removeMessageProducer(BrokerClient, ProducerInfo) - Method in interface org.activemq.broker.Broker
Removes a producer
removeMessageProducer(BrokerClient, ProducerInfo) - Method in class org.activemq.broker.impl.DefaultBroker
 
removeMonitoredChannel(ReliableTransportChannel) - Method in class org.activemq.transport.reliable.KeepAliveDaemon
 
removeNetworkChannel(NetworkChannel) - Method in class org.activemq.transport.NetworkConnector
Removes a network channel
removeNetworkConnector(NetworkConnector) - Method in interface org.activemq.broker.BrokerContainer
Removes the given network connector
removeNetworkConnector(NetworkConnector) - Method in class org.activemq.broker.impl.BrokerContainerImpl
 
removeNode(QueueListSupport.Node) - Method in class org.activemq.service.impl.QueueListSupport
 
removeProducer(ActiveMQMessageProducer) - Method in class org.activemq.ActiveMQSession
 
removeService(DiscoveryEvent) - Method in interface org.activemq.transport.DiscoveryListener
A service has stopped
removeService(DiscoveryEvent) - Method in class org.activemq.transport.DiscoveryNetworkConnector
 
removeService(DiscoveryEvent) - Method in class org.activemq.transport.DiscoveryTransportChannel
 
removeSession(ActiveMQSession) - Method in class org.activemq.ActiveMQConnection
Used interanlly for removing Sessions from a Connection
removeSession(ActiveMQSession) - Method in class org.activemq.TransactionContext
 
removeSubscription(String) - Method in class org.activemq.service.impl.SubscriptionContainerImpl
 
removeSubscription(String) - Method in interface org.activemq.service.SubscriptionContainer
 
removeTemporaryDestination(ActiveMQDestination) - Method in class org.activemq.ActiveMQSession
remove a temporary destination
removeTransportStatusEventListener(TransportStatusEventListener) - Method in interface org.activemq.transport.TransportChannel
Remove a listener for changes in a channels status
removeTransportStatusEventListener(TransportStatusEventListener) - Method in class org.activemq.transport.TransportChannelSupport
Remove a listener for changes in a channels status
removeURI(URI) - Method in class org.activemq.transport.DiscoveryTransportChannel
 
rename(Name, Name) - Method in class org.activemq.jndi.ReadOnlyContext
 
rename(String, String) - Method in class org.activemq.jndi.ReadOnlyContext
 
replayAcknowledge(String, MessageIdentity) - Method in class org.activemq.store.journal.JournalTopicMessageStore
 
replayAddMessage(ActiveMQMessage) - Method in class org.activemq.store.journal.JournalMessageStore
 
replayCommit(Object, boolean) - Method in class org.activemq.store.journal.JournalTransactionStore
 
replayPrepare(Object) - Method in class org.activemq.store.journal.JournalTransactionStore
 
replayRemoveMessage(MessageAck) - Method in class org.activemq.store.journal.JournalMessageStore
 
replayRollback(Object) - Method in class org.activemq.store.journal.JournalTransactionStore
 
replayTransientConsumedRedeliveredMessages(ActiveMQSession, ActiveMQMessageConsumer) - Method in class org.activemq.ActiveMQConnection
 
REPLY_TO - Static variable in interface org.activemq.transport.stomp.Stomp.Headers.Message
 
REPLY_TO - Static variable in interface org.activemq.transport.stomp.Stomp.Headers.Send
 
REPLY_TO_INDEX - Static variable in class org.activemq.message.ActiveMQMessage
 
reponseReceiptReader - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
reponseReceiptWriter - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
requiresEmbeddedBroker() - Method in class org.activemq.transport.activeio.ActiveIOTransportChannelFactory
 
requiresEmbeddedBroker() - Method in class org.activemq.transport.composite.CompositeTransportChannelFactory
 
requiresEmbeddedBroker() - Method in class org.activemq.transport.jabber.JabberTransportChannelFactory
 
requiresEmbeddedBroker() - Method in class org.activemq.transport.multicast.MulticastTransportChannelFactory
 
requiresEmbeddedBroker() - Method in class org.activemq.transport.peer.PeerTransportChannel
Some transports rely on an embedded broker (beer based protocols)
requiresEmbeddedBroker() - Method in class org.activemq.transport.peer.PeerTransportChannelFactory
Does this channel require an embedded broker to perform such as VM or multicast based transports
requiresEmbeddedBroker() - Method in class org.activemq.transport.remote.RemoteTransportChannel
Some transports rely on an embedded broker (beer based protocols)
requiresEmbeddedBroker() - Method in class org.activemq.transport.remote.RemoteTransportChannelFactory
Does this channel require an embedded broker to perform such as VM or multicast based transports
requiresEmbeddedBroker() - Method in class org.activemq.transport.stomp.StompTransportChannelFactory
 
requiresEmbeddedBroker() - Method in class org.activemq.transport.tcp.TcpTransportChannelFactory
 
requiresEmbeddedBroker() - Method in interface org.activemq.transport.TransportChannel
Some transports rely on an embedded broker (peer based protocols)
requiresEmbeddedBroker() - Method in interface org.activemq.transport.TransportChannelFactory
Does this channel require an embedded broker to perform such as VM or multicast based transports
requiresEmbeddedBroker() - Method in class org.activemq.transport.TransportChannelSupport
Some transports rely on an embedded broker (beer based protocols)
requiresEmbeddedBroker() - Method in class org.activemq.transport.udp.UdpTransportChannelFactory
 
requiresEmbeddedBroker() - Method in class org.activemq.transport.vm.VmTransportChannelFactory
 
requiresLayout() - Method in class org.activemq.util.JmsLogAppenderSupport
 
reset(byte[]) - Method in class org.activemq.io.util.ByteArray
reset values
reset(byte[], int, int) - Method in class org.activemq.io.util.ByteArray
reset values
reset() - Method in class org.activemq.io.util.WireByteArrayOutputStream
reset the output stream
reset() - Method in class org.activemq.management.CountStatisticImpl
 
reset() - Method in class org.activemq.management.JMSConnectionStatsImpl
 
reset() - Method in class org.activemq.management.JMSEndpointStatsImpl
 
reset() - Method in class org.activemq.management.JMSSessionStatsImpl
 
reset() - Method in class org.activemq.management.RangeStatisticImpl
 
reset() - Method in interface org.activemq.management.Resettable
Reset the statistic
reset() - Method in class org.activemq.management.StatisticImpl
 
reset() - Method in class org.activemq.management.StatsImpl
 
reset() - Method in class org.activemq.management.TimeStatisticImpl
 
reset() - Method in class org.activemq.message.ActiveMQBytesMessage
Puts the message body in read-only mode and repositions the stream of bytes to the beginning.
reset() - Method in class org.activemq.message.ActiveMQStreamMessage
Puts the message body in read-only mode and repositions the stream of bytes to the beginning.
reset() - Method in class org.activemq.service.impl.DurableQueueMessageContainer
called to reset dispatch pointers if a new Message Consumer joins
reset() - Method in class org.activemq.service.impl.SubscriptionImpl
Called when an active subscriber has closed.
reset() - Method in interface org.activemq.service.QueueMessageContainer
called to reset dispatch pointers if a new Message Consumer joins
reset() - Method in interface org.activemq.service.Subscription
Called when an active message consumer has closed.
reset() - Method in class org.activemq.streams.JMSInputStream
Returns the stream to the position of the previous mark().
reset() - Method in class org.activemq.util.BitArray
reset all the bit values to false
reset(long) - Method in class org.activemq.util.BitArray
reset all the bits to the value supplied
resetMessagePart() - Method in class org.activemq.message.ActiveMQMessage
reset message fragmentation infomation on this message
Resettable - Interface in org.activemq.management
Represents some statistic that is capable of being reset
resolveClass(ObjectStreamClass) - Method in class org.activemq.util.SerializationHelper.ObjectInputStreamExt
 
resolveEntity(String, String) - Method in class org.activemq.spring.ActiveMQDtdResolver
 
resolveHostName(String) - Method in class org.activemq.transport.TransportServerChannelSupport
 
resolveProxyClass(String[]) - Method in class org.activemq.util.SerializationHelper.ObjectInputStreamExt
 
RESPONSE_RECEIPT_INFO - Static variable in interface org.activemq.message.Packet
A receipt with an Object reponse.
ResponseReceipt - Class in org.activemq.message
A receipt that also carries a response object.
ResponseReceipt() - Constructor for class org.activemq.message.ResponseReceipt
 
ResponseReceiptReader - Class in org.activemq.io.impl
Reads a ConsumerInfo object from a Stream
ResponseReceiptReader() - Constructor for class org.activemq.io.impl.ResponseReceiptReader
 
ResponseReceiptWriter - Class in org.activemq.io.impl
Writes a ConsumerInfo object to a Stream
ResponseReceiptWriter() - Constructor for class org.activemq.io.impl.ResponseReceiptWriter
 
restart(byte[], int, int) - Method in class org.activemq.io.util.WireByteArrayInputStream
reset the WireByteArrayInputStream to use an new byte array
restart(byte[]) - Method in class org.activemq.io.util.WireByteArrayInputStream
reset the WireByteArrayInputStream to use an new byte array
restart(int) - Method in class org.activemq.io.util.WireByteArrayOutputStream
start using a fresh byte array
restart() - Method in class org.activemq.io.util.WireByteArrayOutputStream
start using a fresh byte array
restart() - Method in class org.activemq.transport.reliable.KeepAliveDaemon
 
returnConnection(Connection) - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
returnMessage(MessageIdentity) - Method in class org.activemq.service.impl.DurableQueueMessageContainer
 
returnMessage(MessageIdentity) - Method in interface org.activemq.service.QueueMessageContainer
After a poll() on the Container, if a message can't be dispatched, it is returned
right - Variable in class org.activemq.filter.BinaryExpression
 
right - Variable in class org.activemq.filter.UnaryExpression
 
rollback() - Method in class org.activemq.ActiveMQQueueSession
 
rollback() - Method in class org.activemq.ActiveMQSession
Rolls back any messages done in this transaction and releases any locks currently held.
rollback() - Method in class org.activemq.ActiveMQTopicSession
 
rollback() - Method in class org.activemq.ActiveMQXASession
 
ROLLBACK - Static variable in interface org.activemq.message.TransactionType
Rollback a transaction
rollback() - Method in class org.activemq.pool.PooledSession
 
rollback() - Method in class org.activemq.service.impl.AutoCommitTransaction
 
rollback() - Method in class org.activemq.service.impl.LocalTransactionCommand
 
rollback() - Method in class org.activemq.service.impl.XATransactionCommand
 
rollback() - Method in interface org.activemq.service.Transaction
 
rollback(Object) - Method in class org.activemq.store.journal.JournalTransactionStore
 
rollback(Object) - Method in interface org.activemq.store.TransactionStore
 
rollback(Object) - Method in class org.activemq.store.vm.VMTransactionStore
 
rollback() - Method in class org.activemq.TransactionContext
Rolls back any messages done in this transaction and releases any locks currently held.
rollback(Xid) - Method in class org.activemq.TransactionContext
 
rollbackEvent() - Method in interface org.activemq.LocalTransactionEventListener
 
rollbackTransaction(BrokerClient, String) - Method in interface org.activemq.broker.Broker
rollback a transaction
rollbackTransaction(BrokerClient, ActiveMQXid) - Method in interface org.activemq.broker.Broker
 
rollbackTransaction(BrokerClient, String) - Method in interface org.activemq.broker.BrokerConnector
Rollback a transacton
rollbackTransaction(BrokerClient, ActiveMQXid) - Method in interface org.activemq.broker.BrokerConnector
Rollback an XA transaction.
rollbackTransaction(BrokerClient, String) - Method in interface org.activemq.broker.BrokerContainer
Rollback a transacton
rollbackTransaction(BrokerClient, ActiveMQXid) - Method in interface org.activemq.broker.BrokerContainer
Rollback an XA transaction.
rollbackTransaction(BrokerClient, String) - Method in class org.activemq.broker.impl.BrokerConnectorImpl
Rollback a transacton
rollbackTransaction(BrokerClient, ActiveMQXid) - Method in class org.activemq.broker.impl.BrokerConnectorImpl
Rollback an XA transaction.
rollbackTransaction(BrokerClient, String) - Method in class org.activemq.broker.impl.BrokerContainerImpl
Rollback a transacton
rollbackTransaction(BrokerClient, ActiveMQXid) - Method in class org.activemq.broker.impl.BrokerContainerImpl
Rollback an XA transaction.
rollbackTransaction(BrokerClient, String) - Method in class org.activemq.broker.impl.DefaultBroker
rollback a transaction
rollbackTransaction(BrokerClient, ActiveMQXid) - Method in class org.activemq.broker.impl.DefaultBroker
Rollback an XA Transaction.
rollbackTransaction() - Method in class org.activemq.store.cache.CachePersistenceAdapter
 
rollbackTransaction() - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
rollbackTransaction() - Method in class org.activemq.store.journal.JournalPersistenceAdapter
 
rollbackTransaction() - Method in interface org.activemq.store.PersistenceAdapter
Rollback a persistence transaction
rollbackTransaction() - Method in class org.activemq.store.vm.VMPersistenceAdapter
 
rotate() - Method in class org.activemq.service.impl.DefaultQueueList
move the first object to the back of the list
rotate() - Method in class org.activemq.service.impl.QueueListSupport
 
rotate() - Method in interface org.activemq.service.QueueList
Move the head of the list to the back of the list
run() - Method in class org.activemq.ActiveMQQueueSession
 
run() - Method in class org.activemq.ActiveMQSession
Optional operation, intended to be used only by Application Servers, not by ordinary JMS clients.
run() - Method in class org.activemq.ActiveMQSessionExecutor
implementation of Runnable
run() - Method in class org.activemq.ActiveMQTopicSession
 
run() - Method in class org.activemq.pool.PooledSession
 
run() - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageContainer
do some dispatching
run() - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageManager
collect expired messages
run() - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
do some dispatching
run() - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageManager
collect expired messages
run() - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
do some dispatching
run() - Method in class org.activemq.service.impl.DispatchWorker
dispatch messages to active Consumers
run() - Method in interface org.activemq.store.journal.JournalTransactionStore.AddMessageCommand
 
run() - Method in interface org.activemq.store.journal.JournalTransactionStore.RemoveMessageCommand
 
run() - Method in interface org.activemq.store.vm.VMTransactionStore.AddMessageCommand
 
run() - Method in interface org.activemq.store.vm.VMTransactionStore.RemoveMessageCommand
 
run() - Method in class org.activemq.transport.jabber.JabberTransportChannel
 
run() - Method in class org.activemq.transport.multicast.MulticastDiscoveryAgent
send a keep alive message
run() - Method in class org.activemq.transport.reliable.KeepAliveDaemon
 
run() - Method in class org.activemq.transport.tcp.TcpTransportChannel
reads packets from a Socket
run() - Method in class org.activemq.transport.tcp.TcpTransportServerChannel
pull Sockets from the ServerSocket
run() - Method in class org.activemq.transport.udp.UdpTransportChannel
reads packets from a Socket
run() - Method in class org.activemq.transport.vm.VmTransportChannel
reads packets from a Socket
run(Callback) - Method in class org.activemq.util.ExceptionTemplate
 
run(Callback) - Method in class org.activemq.util.TransactionTemplate
 

S

secure(BrokerSecurityConfig) - Static method in class org.activemq.security.jassjacc.JassJaccSecurityAdapter
Creates a JACC PolicyConfiguration for the broker security.
secure(DestinationSecurityConfig) - Static method in class org.activemq.security.jassjacc.JassJaccSecurityAdapter
Creates a JACC PolicyConfiguration for the broker security.
SecurityAdapter - Interface in org.activemq.security
A pluggable strategy to authenticate new connections and authorize the connection and producer and consumer on destinations
SelectorParser - Class in org.activemq.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.activemq.selector.SelectorParser
 
SelectorParser(InputStream) - Constructor for class org.activemq.selector.SelectorParser
 
SelectorParser(Reader) - Constructor for class org.activemq.selector.SelectorParser
 
SelectorParser(SelectorParserTokenManager) - Constructor for class org.activemq.selector.SelectorParser
 
SelectorParserConstants - Interface in org.activemq.selector
 
SelectorParserTokenManager - Class in org.activemq.selector
 
SelectorParserTokenManager(SimpleCharStream) - Constructor for class org.activemq.selector.SelectorParserTokenManager
 
SelectorParserTokenManager(SimpleCharStream, int) - Constructor for class org.activemq.selector.SelectorParserTokenManager
 
send(Message) - Method in class org.activemq.ActiveMQMessageProducer
Sends a message using the MessageProducer's default delivery mode, priority, and time to live.
send(Message, int, int, long) - Method in class org.activemq.ActiveMQMessageProducer
Sends a message to the destination, specifying delivery mode, priority, and time to live.
send(Destination, Message) - Method in class org.activemq.ActiveMQMessageProducer
Sends a message to a destination for an unidentified message producer.
send(Destination, Message, int, int, long) - Method in class org.activemq.ActiveMQMessageProducer
Sends a message to a destination for an unidentified message producer, specifying delivery mode, priority and time to live.
send(Queue, Message) - Method in class org.activemq.ActiveMQQueueSender
Sends a message to a queue for an unidentified message producer.
send(Queue, Message, int, int, long) - Method in class org.activemq.ActiveMQQueueSender
Sends a message to a queue for an unidentified message producer, specifying delivery mode, priority and time to live.
send(ActiveMQMessageProducer, Destination, Message, int, int, long, boolean) - Method in class org.activemq.ActiveMQSession
send the message for dispatch by the broker
send(Packet) - Method in class org.activemq.broker.impl.BrokerClientImpl
 
send(Destination, Message) - Method in class org.activemq.pool.PooledProducer
 
send(Message) - Method in class org.activemq.pool.PooledProducer
 
send(Message, int, int, long) - Method in class org.activemq.pool.PooledProducer
 
send(Destination, Message, int, int, long) - Method in class org.activemq.pool.PooledProducer
 
send(Queue, Message, int, int, long) - Method in class org.activemq.pool.PooledQueueSender
 
send(Queue, Message) - Method in class org.activemq.pool.PooledQueueSender
 
send(Packet) - Method in class org.activemq.transport.composite.CompositeTransportChannel
 
send(Packet, int) - Method in class org.activemq.transport.composite.CompositeTransportChannel
 
send(Packet, int) - Method in class org.activemq.transport.reliable.ReliableTransportChannel
 
SEND - Static variable in interface org.activemq.transport.stomp.Stomp.Commands
 
send(Packet) - Method in interface org.activemq.transport.TransportChannel
synchronously send a Packet
send(Packet, int) - Method in interface org.activemq.transport.TransportChannel
Synchrnously send a Packet
send(Packet) - Method in class org.activemq.transport.TransportChannelSupport
synchronously send a Packet
send(Packet, int) - Method in class org.activemq.transport.TransportChannelSupport
Synchronously send a Packet
SEND_ACTION - Static variable in class org.activemq.security.jassjacc.JMSDestinationPermission
 
sendConnectionInfoToBroker() - Method in class org.activemq.ActiveMQConnection
 
sendConnectionInfoToBroker(int, boolean, boolean) - Method in class org.activemq.ActiveMQConnection
Send the ConnectionInfo to the Broker
sendMatchingInitialImages(BrokerClient, ConsumerInfo, DestinationFilter) - Method in class org.activemq.service.impl.InitialImageMessageContainerManager
 
sendMessage(BrokerClient, ActiveMQMessage) - Method in interface org.activemq.broker.Broker
send a message to the broker
sendMessage(BrokerClient, ActiveMQMessage) - Method in interface org.activemq.broker.BrokerConnector
Send a non-transacted message to the Broker
sendMessage(BrokerClient, ActiveMQMessage) - Method in interface org.activemq.broker.BrokerContainer
Send a non-transacted message to the Broker
sendMessage(BrokerClient, ActiveMQMessage) - Method in class org.activemq.broker.impl.BrokerConnectorImpl
Send a non-transacted message to the Broker
sendMessage(BrokerClient, ActiveMQMessage) - Method in class org.activemq.broker.impl.BrokerContainerImpl
Send a non-transacted message to the Broker
sendMessage(BrokerClient, ActiveMQMessage) - Method in class org.activemq.broker.impl.DefaultBroker
send a message to the broker
sendMessage(BrokerClient, ActiveMQMessage) - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageManager
 
sendMessage(BrokerClient, ActiveMQMessage) - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageManager
 
sendMessage(BrokerClient, ActiveMQMessage) - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageManager
 
sendMessage(BrokerClient, ActiveMQMessage) - Method in class org.activemq.service.impl.DurableQueueMessageContainerManager
 
sendMessage(BrokerClient, ActiveMQMessage) - Method in class org.activemq.service.impl.DurableTopicMessageContainerManager
 
sendMessage(BrokerClient, ActiveMQMessage) - Method in class org.activemq.service.impl.InitialImageMessageContainerManager
 
sendMessage(BrokerClient, ActiveMQMessage) - Method in class org.activemq.service.impl.ProxyMessageContainerManager
 
sendMessage(BrokerClient, ActiveMQMessage) - Method in class org.activemq.service.impl.TransientTopicMessageContainerManager
 
sendMessage(BrokerClient, ActiveMQMessage) - Method in interface org.activemq.service.MessageContainerManager
 
sendMessageRateTime - Variable in class org.activemq.management.JMSQueueStatsImpl
 
sendToDeadLetter(ActiveMQMessage) - Method in class org.activemq.service.DeadLetterPolicy
Send a message to a dead letter queue
sendToDeadLetter(ActiveMQMessage) - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
sendToDeadLetterQueue(String, ActiveMQMessage) - Method in interface org.activemq.broker.Broker
Add a message to a dead letter queue
sendToDeadLetterQueue(String, ActiveMQMessage) - Method in class org.activemq.broker.impl.DefaultBroker
Add a message to a dead letter queue
sendToDeadLetterQueue(String, ActiveMQMessage) - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageManager
 
sendToDeadLetterQueue(String, ActiveMQMessage) - Method in class org.activemq.service.impl.DurableQueueMessageContainerManager
Add a message to a dead letter queue
sendToDeadLetterQueue(String, ActiveMQMessage) - Method in interface org.activemq.service.QueueMessageContainerManager
Add a message to a dead letter queue
SEPARATOR - Static variable in class org.activemq.filter.DestinationPath
 
SEPARATOR - Static variable in class org.activemq.jndi.ReadOnlyContext
 
SEPERATOR - Static variable in interface org.activemq.transport.stomp.Stomp.Headers
 
sequenceDataType - Variable in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
sequenceGenerator - Variable in class org.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
sequenceGenerator - Variable in class org.activemq.store.jdbc.JDBCMessageStore
 
SerializationHelper - Class in org.activemq.util
 
SerializationHelper() - Constructor for class org.activemq.util.SerializationHelper
 
SerializationHelper.ObjectInputStreamExt - Class in org.activemq.util
 
SerializationHelper.ObjectInputStreamExt(InputStream) - Constructor for class org.activemq.util.SerializationHelper.ObjectInputStreamExt
 
Service - Interface in org.activemq.service
Service represents some service of some kind with a simple start/stop lifecycle.
serviceName - Variable in class org.activemq.transport.peer.PeerTransportChannel
 
session - Variable in class org.activemq.ActiveMQMessageConsumer
 
session - Variable in class org.activemq.ActiveMQMessageProducer
 
SESSION - Static variable in interface org.activemq.transport.stomp.Stomp.Headers.Connected
 
SESSION_INFO - Static variable in interface org.activemq.message.Packet
Session Info message
SessionInfo - Class in org.activemq.message
Denotes an object that can be serialized/deserailized using a Packet Reader/Writer
SessionInfo() - Constructor for class org.activemq.message.SessionInfo
 
sessionInfoReader - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
SessionInfoReader - Class in org.activemq.io.impl
Reads a ConsumerInfo object from a Stream
SessionInfoReader() - Constructor for class org.activemq.io.impl.SessionInfoReader
 
sessionInfoWriter - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
SessionInfoWriter - Class in org.activemq.io.impl
Writes a ConsumerInfo object to a Stream
SessionInfoWriter() - Constructor for class org.activemq.io.impl.SessionInfoWriter
 
SessionKey - Class in org.activemq.pool
A cache key for the session details
SessionKey(boolean, int) - Constructor for class org.activemq.pool.SessionKey
 
SessionPool - Class in org.activemq.pool
Represents the session pool for a given JMS connection.
SessionPool(ActiveMQConnection, SessionKey) - Constructor for class org.activemq.pool.SessionPool
 
SessionPool(ActiveMQConnection, SessionKey, ObjectPool) - Constructor for class org.activemq.pool.SessionPool
 
set(int, Object) - Method in class org.activemq.service.impl.DefaultQueueList
 
set(int, Object) - Method in class org.activemq.service.impl.QueueListSupport
 
set(int, Object) - Method in interface org.activemq.service.QueueList
Replaces the element at the specified position in this list with the specified element.
set(int, boolean) - Method in class org.activemq.util.BitArray
set the boolean value at the index
SET_TX_TIMEOUT - Static variable in interface org.activemq.message.TransactionType
Set a the transaction timeout for the RM
setActive(boolean) - Method in class org.activemq.service.impl.SubscriptionImpl
 
setActive(boolean) - Method in interface org.activemq.service.Subscription
set the state of the Subscription
setActiveConsumer(BrokerClient, ConsumerInfo) - Method in class org.activemq.service.impl.SubscriptionImpl
Set the active consumer info
setActiveConsumer(BrokerClient, ConsumerInfo) - Method in interface org.activemq.service.Subscription
Set the active consumer info
setAdapterClass(String) - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
setAdvisory(boolean) - Method in class org.activemq.message.ActiveMQDestination
 
setAllowDuplicates(boolean) - Method in class org.activemq.service.DeadLetterPolicy
 
setAsyncSend(boolean) - Method in class org.activemq.transport.vm.VmTransportChannel
 
setAutoCleanupExpiredMessages(boolean) - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
setBacklog(int) - Method in class org.activemq.transport.tcp.TcpTransportServerChannel
 
setBackOffIncreaseRate(double) - Method in class org.activemq.service.RedeliveryPolicy
 
setBackOffMode(boolean) - Method in class org.activemq.service.RedeliveryPolicy
 
setBinaryData(PreparedStatement, int, byte[]) - Method in class org.activemq.store.jdbc.adapter.BytesJDBCAdapter
 
setBinaryData(PreparedStatement, int, byte[]) - Method in class org.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
setBinaryData(PreparedStatement, int, byte[]) - Method in class org.activemq.store.jdbc.adapter.StreamJDBCAdapter
 
setBinaryDataType(String) - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
setBit(long, boolean) - Method in class org.activemq.util.BitArrayBin
Set a bit
setBitArray(BitArray) - Method in class org.activemq.message.AbstractPacket
 
setBodyAsBytes(byte[], int, int) - Method in class org.activemq.message.ActiveMQBytesMessage
 
setBodyAsBytes(byte[], int, int) - Method in class org.activemq.message.ActiveMQMessage
 
setBodyAsBytes(ByteArray) - Method in class org.activemq.message.ActiveMQMessage
set the body as bytes
setBodyAsBytes(byte[], int, int) - Method in class org.activemq.message.ActiveMQStreamMessage
 
setBoolean(String, boolean) - Method in class org.activemq.message.ActiveMQMapMessage
Sets a boolean value with the specified name into the Map.
setBooleanProperty(String, boolean) - Method in class org.activemq.message.ActiveMQMessage
Sets a boolean property value with the specified name into the message.
setBroker(Broker) - Method in class org.activemq.service.DeadLetterPolicy
 
setBrokerConnectorURI(String) - Method in class org.activemq.transport.peer.PeerTransportChannel
 
setBrokercontainer(BrokerContainerImpl) - Method in class org.activemq.broker.impl.DefaultBroker
 
setBrokerContainer(BrokerContainer) - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
setBrokerContainer(BrokerContainer) - Method in class org.activemq.transport.NetworkChannel
 
setBrokerContainerFactory(BrokerContainerFactory) - Method in class org.activemq.ActiveMQConnectionFactory
 
setBrokerContext(BrokerContext) - Method in class org.activemq.ActiveMQConnectionFactory
 
setBrokerMessageCapacity(int) - Method in class org.activemq.message.Receipt
 
setBrokerName(String) - Method in class org.activemq.ActiveMQConnectionFactory
 
setBrokerName(String) - Method in class org.activemq.broker.impl.LocalBrokerInfo
 
setBrokerName(String) - Method in class org.activemq.message.BrokerInfo
 
setBrokerName(String) - Method in class org.activemq.message.Receipt
 
setBrokerName(String) - Method in class org.activemq.security.jassjacc.BrokerSecurityConfig
 
setBrokerName(String) - Method in class org.activemq.security.jassjacc.DestinationSecurityConfig
 
setBrokerName(String) - Method in class org.activemq.spring.ActiveMQBeanDefinitionReader
 
setBrokerName(String) - Method in class org.activemq.transport.peer.PeerTransportChannel
 
setBrokerName(String) - Method in class org.activemq.transport.remote.RemoteTransportChannel
 
setBrokersVisitedAsString(String) - Method in class org.activemq.message.AbstractPacket
 
setBrokerURL(String) - Method in class org.activemq.ActiveMQConnectionFactory
 
setBrokerXmlConfig(String) - Method in class org.activemq.ActiveMQConnectionFactory
Sets the XML configuration file used to configure the ActiveMQ broker via Spring if using embedded mode.
setBrowser(boolean) - Method in class org.activemq.ActiveMQMessageConsumer
Set true if only a Browser
setBrowser(boolean) - Method in class org.activemq.message.ConsumerInfo
 
setBuf(byte[]) - Method in class org.activemq.io.util.ByteArray
 
setByte(String, byte) - Method in class org.activemq.message.ActiveMQMapMessage
Sets a byte value with the specified name into the Map.
setByteProperty(String, byte) - Method in class org.activemq.message.ActiveMQMessage
Sets a byte property value with the specified name into the message.
setBytes(String, byte[]) - Method in class org.activemq.message.ActiveMQMapMessage
Sets a byte array value with the specified name into the Map.
setBytes(String, byte[], int, int) - Method in class org.activemq.message.ActiveMQMapMessage
Sets a portion of the byte array value with the specified name into the Map.
setCacheMessageStore(CacheMessageStore) - Method in class org.activemq.store.cache.CacheMessageStore
 
setCacheMessageStore(CacheMessageStore) - Method in interface org.activemq.store.cache.CacheMessageStoreAware
 
setCacheMessageStore(CacheMessageStore) - Method in class org.activemq.store.journal.JournalMessageStore
 
setCacheSize(int) - Method in class org.activemq.store.cache.SimpleCachePersistenceAdapter
 
setCachingEnabled(boolean) - Method in class org.activemq.ActiveMQConnection
 
setCachingEnabled(boolean) - Method in class org.activemq.ActiveMQConnectionFactory
 
setCachingEnabled(boolean) - Method in class org.activemq.io.AbstractWireFormat
 
setCachingEnabled(boolean) - Method in interface org.activemq.io.WireFormat
 
setCachingEnabled(boolean) - Method in class org.activemq.transport.stomp.StompWireFormat
 
setCachingEnabled(boolean) - Method in interface org.activemq.transport.TransportChannel
 
setCachingEnabled(boolean) - Method in class org.activemq.transport.TransportChannelSupport
 
setCapacity(int) - Method in class org.activemq.capacity.CapacityMonitorEvent
 
setCapacity(int) - Method in class org.activemq.message.CapacityInfo
 
setChannelName(String) - Method in class org.activemq.transport.multicast.MulticastDiscoveryAgent
 
setChannelStatus(int) - Method in class org.activemq.transport.TransportStatusEvent
 
setChar(String, char) - Method in class org.activemq.message.ActiveMQMapMessage
Sets a Unicode character value with the specified name into the Map.
setCheckInterval(long) - Method in class org.activemq.transport.reliable.KeepAliveDaemon
Sets the number of milliseconds between keep-alive checks are done.
setCheckpointInterval(long) - Method in class org.activemq.store.journal.JournalPersistenceAdapter
 
setChildDestinations(ActiveMQDestination[]) - Method in class org.activemq.message.ActiveMQDestination
 
setCleanupPeriod(int) - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
setCleanupRepeatInterval(long) - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
setClientID(String) - Method in class org.activemq.ActiveMQConnection
Sets the client identifier for this connection.
setClientID(String) - Method in class org.activemq.ActiveMQConnectionFactory
 
setClientId(String) - Method in class org.activemq.message.CleanupConnectionInfo
 
setClientId(String) - Method in class org.activemq.message.ConnectionInfo
 
setClientId(String) - Method in class org.activemq.message.ConsumerInfo
 
setClientId(String) - Method in class org.activemq.message.DurableUnsubscribe
 
setClientId(String) - Method in class org.activemq.message.ProducerInfo
 
setClientId(String) - Method in class org.activemq.message.SessionInfo
 
setClientID(String) - Method in class org.activemq.pool.PooledConnection
 
setClientId(String) - Method in class org.activemq.service.impl.SubscriptionImpl
 
setClientID(String) - Method in class org.activemq.service.SubscriberEntry
 
setClientID(String) - Method in class org.activemq.transport.composite.CompositeTransportChannel
 
setClientID(String) - Method in class org.activemq.transport.remote.RemoteTransportChannel
Provides a way to specify the client ID that this channel is using
setClientID(String) - Method in interface org.activemq.transport.TransportChannel
Provides a way to specify the client ID that this channel is using
setClientID(String) - Method in class org.activemq.transport.TransportChannelSupport
 
setClientVersion(String) - Method in class org.activemq.message.ConnectionInfo
 
setClockDaemon(ClockDaemon) - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
setClockDaemon(ClockDaemon) - Method in class org.activemq.store.journal.JournalPersistenceAdapter
 
setClosed(boolean) - Method in class org.activemq.message.ConnectionInfo
 
setClusterName(String) - Method in class org.activemq.broker.impl.LocalBrokerInfo
 
setClusterName(String) - Method in class org.activemq.message.BrokerInfo
 
setClusterName(String) - Method in class org.activemq.message.Receipt
 
setCommand(String) - Method in class org.activemq.message.BrokerAdminCommand
 
setCompressionLevel(int) - Method in class org.activemq.io.util.ByteArrayCompression
 
setCompressionLimit(int) - Method in class org.activemq.io.util.ByteArrayCompression
 
setCompressionStrategy(int) - Method in class org.activemq.io.util.ByteArrayCompression
 
setConfig(Resource) - Method in class org.activemq.spring.BrokerFactoryBean
 
setConnection(Connection) - Method in class org.activemq.util.JmsLogAppenderSupport
 
setConnectionFactory(ActiveMQConnectionFactory) - Method in class org.activemq.pool.PooledConnectionFactory
 
setConnectionMemoryLimit(int) - Method in class org.activemq.ActiveMQConnection
Set the maximum amount of memory this Connection should use for buffered inbound messages
setConnectionPrefix(String) - Method in class org.activemq.jndi.ActiveMQInitialContextFactory
 
setConnectRoles(HashSet) - Method in class org.activemq.security.jassjacc.BrokerSecurityConfig
 
setConsumerId(String) - Method in class org.activemq.message.ConsumerInfo
 
setConsumerId(String) - Method in class org.activemq.message.MessageAck
 
setConsumerIdentifer(String) - Method in class org.activemq.message.ActiveMQMessage
 
setConsumerInfo(ConsumerInfo) - Method in class org.activemq.service.boundedvm.DurableSubscription
 
setConsumerInfo(ConsumerInfo) - Method in class org.activemq.service.boundedvm.TransientSubscription
 
setConsumerName(String) - Method in class org.activemq.ActiveMQMessageConsumer
Set the name of the Consumer - used for durable subscribers
setConsumerName(String) - Method in class org.activemq.message.ConsumerInfo
 
setConsumerName(String) - Method in class org.activemq.service.SubscriberEntry
 
setConsumerNo(int) - Method in class org.activemq.message.ConsumerInfo
 
setConsumerNos(int[]) - Method in class org.activemq.message.ActiveMQMessage
 
setConsumerNosAsString(String) - Method in class org.activemq.message.ActiveMQMessage
Sets the consumer numbers using a String format
setConsumerNumber(int) - Method in class org.activemq.ActiveMQMessageConsumer
Set the locally unique consumer number
setConsumeRoles(HashSet) - Method in class org.activemq.security.jassjacc.DestinationSecurityConfig
 
setContainerManagerMap(Map) - Method in class org.activemq.broker.impl.DefaultBroker
 
setContainerNameDataType(String) - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
setContexTransaction(Transaction) - Static method in class org.activemq.service.TransactionManager
 
setCopyMessageOnSend(boolean) - Method in class org.activemq.ActiveMQConnection
 
setCopyMessageOnSend(boolean) - Method in class org.activemq.ActiveMQConnectionFactory
 
setCorrelationId(short) - Method in class org.activemq.message.CapacityInfo
 
setCorrelationId(short) - Method in class org.activemq.message.Receipt
 
setCount(long) - Method in class org.activemq.management.CountStatisticImpl
 
setCurrent(long) - Method in class org.activemq.management.RangeStatisticImpl
 
setCurrentValue(long) - Method in class org.activemq.capacity.BasicCapacityMonitor
set the current value of the capacity
setCurrentValue(long) - Method in interface org.activemq.capacity.CapacityMonitor
set the current value of the capacity
setCurrentValue(long) - Method in class org.activemq.capacity.DelegateCapacityMonitor
set the current value of the capacity
setCurrentWireFormatVersion(int) - Method in class org.activemq.io.impl.AbstractDefaultWireFormat
set the current version
setDataSource(DataSource) - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
setDeadLetterEnabled(boolean) - Method in class org.activemq.service.DeadLetterPolicy
 
setDeadLetterName(String) - Method in class org.activemq.service.DeadLetterPolicy
 
setDeadLetterPerDestinationName(boolean) - Method in class org.activemq.service.DeadLetterPolicy
 
setDeadLetterPolicy(DeadLetterPolicy) - Method in interface org.activemq.broker.Broker
set the dead letter policy
setDeadLetterPolicy(DeadLetterPolicy) - Method in class org.activemq.broker.impl.BrokerContainerImpl
 
setDeadLetterPolicy(DeadLetterPolicy) - Method in class org.activemq.broker.impl.DefaultBroker
set the dead letter policy
setDeadLetterPolicy(DeadLetterPolicy) - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageManager
Set the DeadLetterPolicy for this Container Manager
setDeadLetterPolicy(DeadLetterPolicy) - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageManager
Set the DeadLetterPolicy for this Container Manager
setDeadLetterPolicy(DeadLetterPolicy) - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageManager
Set the DeadLetterPolicy for this Container Manager
setDeadLetterPolicy(DeadLetterPolicy) - Method in class org.activemq.service.impl.MessageContainerManagerSupport
Set the DeadLetterPolicy for this Container Manager
setDeadLetterPolicy(DeadLetterPolicy) - Method in class org.activemq.service.impl.ProxyMessageContainerManager
Set the DeadLetterPolicy for this Container Manager
setDeadLetterPolicy(DeadLetterPolicy) - Method in interface org.activemq.service.MessageContainerManager
Set the DeadLetterPolicy for this Container Manager
setDeadLetterPolicy(DeadLetterPolicy) - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
setDeadLetterPrefix(String) - Method in class org.activemq.service.DeadLetterPolicy
 
setDeadLetterQueue(boolean) - Method in class org.activemq.service.impl.DurableQueueMessageContainer
 
setDeadLetterQueue(boolean) - Method in interface org.activemq.service.QueueMessageContainer
set this MessageContainer to be a dead letter queue
setDeadLetterQueueTTL(long) - Method in class org.activemq.service.DeadLetterPolicy
 
setDeadLetterTopicTTL(long) - Method in class org.activemq.service.DeadLetterPolicy
 
setDebugStream(PrintStream) - Method in class org.activemq.selector.SelectorParserTokenManager
 
setDecoupledDispatch(boolean) - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageManager
 
setDelegate(CapacityMonitor) - Method in class org.activemq.capacity.DelegateCapacityMonitor
Set the delegated one
setDelegate(MessageContainerManager) - Method in class org.activemq.service.impl.ProxyMessageContainerManager
 
setDeleted(boolean) - Method in class org.activemq.message.ActiveMQDestination
det the deleted flag to the new value
setDeleteExpiredMessages(boolean) - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
setDeliveryCount(int) - Method in class org.activemq.message.ActiveMQMessage
 
setDeliveryListener(ActiveMQSession.DeliveryListener) - Method in class org.activemq.ActiveMQSession
 
setDeliveryMode(int) - Method in class org.activemq.ActiveMQMessageProducer
Sets the producer's default delivery mode.
setDeliveryMode(int) - Method in class org.activemq.pool.PooledProducer
 
setDemandBasedForwarding(boolean) - Method in class org.activemq.transport.NetworkChannel
 
setDemandListener(ProducerDemandListener) - Method in class org.activemq.advisories.ProducerDemandAdvisor
 
setDestination(ActiveMQDestination) - Method in class org.activemq.advisories.TempDestinationAdvisoryEvent
 
setDestination(ActiveMQDestination) - Method in class org.activemq.message.BrokerAdminCommand
 
setDestination(ActiveMQDestination) - Method in class org.activemq.message.ConsumerInfo
 
setDestination(ActiveMQDestination) - Method in class org.activemq.message.MessageAck
 
setDestination(ActiveMQDestination) - Method in class org.activemq.message.ProducerInfo
 
setDestination(ActiveMQDestination) - Method in class org.activemq.security.jassjacc.DestinationSecurityConfig
 
setDestination(String) - Method in class org.activemq.service.SubscriberEntry
 
setDestination(String) - Method in class org.activemq.store.journal.JournalAck
 
setDirectory(File) - Method in class org.activemq.store.journal.JournalPersistenceAdapter
 
setDisableMessageID(boolean) - Method in class org.activemq.ActiveMQMessageProducer
Sets whether message IDs are disabled.
setDisableMessageID(boolean) - Method in class org.activemq.pool.PooledProducer
 
setDisableMessageTimestamp(boolean) - Method in class org.activemq.ActiveMQMessageProducer
Sets whether message timestamps are disabled.
setDisableMessageTimestamp(boolean) - Method in class org.activemq.pool.PooledProducer
 
setDisableTimeStampsByDefault(boolean) - Method in class org.activemq.ActiveMQConnection
 
setDisableTimeStampsByDefault(boolean) - Method in class org.activemq.ActiveMQConnectionFactory
 
setDiscoveryAgent(DiscoveryAgent) - Method in interface org.activemq.broker.BrokerContainer
 
setDiscoveryAgent(DiscoveryAgent) - Method in class org.activemq.broker.impl.BrokerContainerImpl
 
setDiscoveryAgent(DiscoveryAgent) - Method in class org.activemq.transport.DiscoveryTransportChannel
 
setDiscoveryAgent(DiscoveryAgent) - Method in class org.activemq.transport.DiscoveryTransportChannelFactorySupport
 
setDiscoveryURI(String) - Method in class org.activemq.transport.peer.PeerTransportChannel
 
setDispatchedFromDLQ(boolean) - Method in class org.activemq.message.ActiveMQMessage
 
setDoDiscovery(boolean) - Method in class org.activemq.transport.peer.PeerTransportChannel
 
setDoMessageCompression(boolean) - Method in class org.activemq.ActiveMQConnection
 
setDoMessageCompression(boolean) - Method in class org.activemq.ActiveMQConnectionFactory
 
setDoMessageFragmentation(boolean) - Method in class org.activemq.ActiveMQConnection
 
setDoMessageFragmentation(boolean) - Method in class org.activemq.ActiveMQConnectionFactory
 
setDouble(String, double) - Method in class org.activemq.message.ActiveMQMapMessage
Sets a double value with the specified name into the Map.
setDoubleProperty(String, double) - Method in class org.activemq.message.ActiveMQMessage
Sets a double property value with the specified name into the message.
setDropTablesOnStartup(boolean) - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
setDurableSubAcksTableName(String) - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
setDurableTopicPrefetch(int) - Method in class org.activemq.ActiveMQPrefetchPolicy
 
setEntryBrokerName(String) - Method in class org.activemq.message.ActiveMQMessage
 
setEntryClusterName(String) - Method in class org.activemq.message.ActiveMQMessage
 
setEstablishConnectionTimeout(long) - Method in class org.activemq.transport.composite.CompositeTransportChannel
 
setException(Throwable) - Method in class org.activemq.message.Receipt
 
setExceptionAsString(String) - Method in class org.activemq.message.Receipt
OpenWire helper method
setExceptionListener(ExceptionListener) - Method in class org.activemq.ActiveMQConnection
Sets an exception listener for this connection.
setExceptionListener(ExceptionListener) - Method in class org.activemq.pool.PooledConnection
 
setExceptionListener(ExceptionListener) - Method in class org.activemq.transport.composite.CompositeTransportChannel
 
setExceptionListener(ExceptionListener) - Method in interface org.activemq.transport.TransportChannel
Set an exception listener to listen for asynchronously generated exceptions
setExceptionListener(ExceptionListener) - Method in class org.activemq.transport.TransportChannelSupport
Set an exception listener to listen for asynchronously generated exceptions
setExceptionListener(ExceptionListener) - Method in class org.activemq.util.MessageListenerSupport
 
setExclusive(boolean) - Method in class org.activemq.message.ActiveMQDestination
 
setExpired(boolean) - Method in class org.activemq.message.MessageAck
 
setExternalMessageId(boolean) - Method in class org.activemq.message.ActiveMQMessage
 
setExternalMessageId(boolean) - Method in class org.activemq.message.MessageAck
 
setFailed(boolean) - Method in class org.activemq.message.Receipt
 
setFailureSleepTime(long) - Method in class org.activemq.transport.composite.CompositeTransportChannel
 
setFilter(Filter) - Method in class org.activemq.service.boundedvm.DurableSubscription
 
setFilter(Filter) - Method in class org.activemq.service.boundedvm.TransientSubscription
 
setFilter(Filter) - Method in class org.activemq.service.impl.SubscriptionImpl
 
setFloat(String, float) - Method in class org.activemq.message.ActiveMQMapMessage
Sets a float value with the specified name into the Map.
setFloatProperty(String, float) - Method in class org.activemq.message.ActiveMQMessage
Sets a float property value with the specified name into the message.
setFlowControlTimeout(long) - Method in class org.activemq.message.CapacityInfo
 
setFragmentationLimit(int) - Method in class org.activemq.io.util.ByteArrayFragmentation
 
setGarbageCoolectionCapacityLimit(int) - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageManager
 
setGarbageCoolectionCapacityLimit(int) - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageManager
 
setGrowthLimit(float) - Method in class org.activemq.io.util.MemoryBoundedMessageCache
 
setHostName(String) - Method in class org.activemq.message.ConnectionInfo
 
setId(short) - Method in class org.activemq.message.AbstractPacket
Set the unique id for this Packet
setId(short) - Method in interface org.activemq.message.Packet
Set the unique id for this Packet
setInactiveTimeout(long) - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageManager
 
setInactiveTimeout(long) - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageManager
 
setIncrementTimeout(boolean) - Method in class org.activemq.transport.composite.CompositeTransportChannel
 
setIndentLevel(int) - Method in class org.activemq.util.IndentPrinter
 
setInitialContextFactoryName(String) - Method in class org.activemq.util.JndiJmsLogAppender
 
setInitialRedeliveryTimeout(long) - Method in class org.activemq.service.RedeliveryPolicy
 
setInt(String, int) - Method in class org.activemq.message.ActiveMQMapMessage
Sets an int value with the specified name into the Map.
setInternalConnection(boolean) - Method in class org.activemq.ActiveMQConnection
 
setInternalConnection(boolean) - Method in class org.activemq.ActiveMQConnectionFactory
 
setInternalSession(boolean) - Method in class org.activemq.ActiveMQSession
 
setIntProperty(String, int) - Method in class org.activemq.message.ActiveMQMessage
Sets an int property value with the specified name into the message.
setJ2EEcompliant(boolean) - Method in class org.activemq.ActiveMQConnection
 
setJ2EEcompliant(boolean) - Method in class org.activemq.ActiveMQConnectionFactory
 
setJMSClientID(String) - Method in class org.activemq.message.ActiveMQMessage
 
setJMSCorrelationID(String) - Method in class org.activemq.message.ActiveMQMessage
Sets the correlation ID for the message.
setJMSCorrelationIDAsBytes(byte[]) - Method in class org.activemq.message.ActiveMQMessage
Sets the correlation ID as an array of bytes for the message.
setJMSDeliveryMode(int) - Method in class org.activemq.message.ActiveMQMessage
Sets the DeliveryMode value for this message.
setJMSDestination(Destination) - Method in class org.activemq.message.ActiveMQMessage
Sets the Destination object for this message.
setJMSExpiration(long) - Method in class org.activemq.message.ActiveMQMessage
Sets the message's expiration value.
setJMSMessageID(String) - Method in class org.activemq.message.ActiveMQMessage
Sets the message ID.
setJMSMessageIdentity(MessageIdentity) - Method in class org.activemq.message.ActiveMQMessage
 
setJMSPriority(int) - Method in class org.activemq.message.ActiveMQMessage
Sets the priority level for this message.
setJMSRedelivered(boolean) - Method in class org.activemq.message.ActiveMQMessage
Specifies whether this message is being redelivered.
setJMSReplyTo(Destination) - Method in class org.activemq.message.ActiveMQMessage
Sets the Destination object to which a reply to this message should be sent.
setJMSTimestamp(long) - Method in class org.activemq.message.ActiveMQMessage
Sets the message timestamp.
setJMSType(String) - Method in class org.activemq.message.ActiveMQMessage
Sets the message type.
setJndiName(String) - Method in class org.activemq.util.JndiJmsLogAppender
 
setJournalType(String) - Method in class org.activemq.store.journal.JournalPersistenceAdapter
 
setKeepAliveTimeout(long) - Method in class org.activemq.transport.multicast.MulticastDiscoveryAgent
 
setKeepAliveTimeout(long) - Method in class org.activemq.transport.reliable.ReliableTransportChannel
Sets the number of milliseconds this channel can be idle after a keep-alive packet has been sent without being disconnected.
setLastAcknowledgedMessageID(Subscription, MessageIdentity) - Method in class org.activemq.service.impl.DurableTopicMessageContainer
 
setLastAcknowledgedMessageID(Subscription, MessageIdentity) - Method in interface org.activemq.service.TopicMessageContainer
Sets the last acknowleged message ID for the given subscriber in this container so that if we shut down and recover we know where to start replaying messages from.
setLastAcknowledgedMessageIdentity(String, MessageIdentity) - Method in class org.activemq.store.cache.CacheTopicMessageStore
 
setLastAcknowledgedMessageIdentity(String, MessageIdentity) - Method in class org.activemq.store.jdbc.JDBCTopicMessageStore
 
setLastAcknowledgedMessageIdentity(String, MessageIdentity) - Method in class org.activemq.store.journal.JournalTopicMessageStore
 
setLastAcknowledgedMessageIdentity(String, MessageIdentity) - Method in class org.activemq.store.ProxyTopicMessageStore
 
setLastAcknowledgedMessageIdentity(String, MessageIdentity) - Method in interface org.activemq.store.TopicMessageStore
Stores the last acknowledged messgeID for the given subscription so that we can recover and commence dispatching messages from the last checkpoint
setLastAcknowledgedMessageIdentity(String, MessageIdentity) - Method in class org.activemq.store.vm.VMTopicMessageStore
 
setLastMessageIdentifier(MessageIdentity) - Method in class org.activemq.service.impl.SubscriptionImpl
 
setLastMessageIdentifier(MessageIdentity) - Method in interface org.activemq.service.Subscription
Used for a Queue based Subscription to set the last acknowledged message ID
setLastSequenceId(long) - Method in class org.activemq.util.LongSequenceGenerator
 
setLeft(Expression) - Method in class org.activemq.filter.BinaryExpression
 
setLength(int) - Method in class org.activemq.io.util.ByteArray
 
setLocalDetails(Map) - Method in class org.activemq.transport.NetworkConnector
 
setLocalDurableTopicPrefetch(int) - Method in class org.activemq.transport.NetworkConnector
 
setLocalId(String) - Method in class org.activemq.transport.multicast.MulticastDiscoveryAgent
 
setLocalId(String) - Method in class org.activemq.transport.multicast.MulticastTester
 
setLocalPrefetchPolicy(ActiveMQPrefetchPolicy) - Method in class org.activemq.transport.NetworkChannel
 
setLocalPrefetchPolicy(ActiveMQPrefetchPolicy) - Method in class org.activemq.transport.NetworkConnector
 
setLocalQueueBrowserPrefetch(int) - Method in class org.activemq.transport.NetworkConnector
 
setLocalQueuePrefetch(int) - Method in class org.activemq.transport.NetworkConnector
 
setLocalTopicPrefetch(int) - Method in class org.activemq.transport.NetworkConnector
 
setLocalTransactionEventListener(LocalTransactionEventListener) - Method in class org.activemq.TransactionContext
Used by the resource adapter to listen to transaction events.
setLogFileCount(int) - Method in class org.activemq.store.journal.JournalPersistenceAdapter
 
setLogFileSize(int) - Method in class org.activemq.store.journal.JournalPersistenceAdapter
 
setLong(String, long) - Method in class org.activemq.message.ActiveMQMapMessage
Sets a long value with the specified name into the Map.
setLongDataType(String) - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
setLongProperty(String, long) - Method in class org.activemq.message.ActiveMQMessage
Sets a long property value with the specified name into the message.
setLongTermPersistence(PersistenceAdapter) - Method in class org.activemq.store.cache.CachePersistenceAdapter
 
setLongTermPersistence(PersistenceAdapter) - Method in class org.activemq.store.journal.JournalPersistenceAdapter
 
setMaintainDestinationStats(boolean) - Method in class org.activemq.service.impl.MessageContainerManagerSupport
 
setMaximumMemoryUsage(long) - Method in class org.activemq.broker.impl.DefaultBroker
 
setMaximumRetries(int) - Method in class org.activemq.transport.composite.CompositeTransportChannel
 
setMaximumRetries(int) - Method in class org.activemq.transport.NetworkChannel
 
setMaximumRetryCount(int) - Method in class org.activemq.service.RedeliveryPolicy
 
setMaximumTimeout(long) - Method in class org.activemq.transport.composite.CompositeTransportChannel
 
setMaxOutstandingMessages(int) - Method in class org.activemq.transport.tcp.TcpTransportServerChannel
 
setMemoryLimitEnforced(boolean) - Method in class org.activemq.io.util.MemoryBoundedQueueManager
 
setMemoryManager(MemoryBoundedObjectManager) - Method in class org.activemq.store.cache.MemoryBoundedCachePersistenceAdapter
 
setMemoryUsage(int) - Method in class org.activemq.message.AbstractPacket
Set a hint about how mujch memory this packet is consuming
setMemoryUsage(int) - Method in interface org.activemq.message.Packet
Set a hint about how mujch memory this packet is consuming
setMessageAcknowledge(MessageAcknowledge) - Method in class org.activemq.message.ActiveMQMessage
 
setMessageCompressionLevel(int) - Method in class org.activemq.ActiveMQConnection
 
setMessageCompressionLimit(int) - Method in class org.activemq.ActiveMQConnection
 
setMessageCompressionLimit(int) - Method in class org.activemq.ActiveMQConnectionFactory
 
setMessageCompressionStrategy(int) - Method in class org.activemq.ActiveMQConnection
 
setMessageCompressionStrategy(int) - Method in class org.activemq.ActiveMQConnectionFactory
 
setMessageConsumed(boolean) - Method in class org.activemq.message.ActiveMQMessage
 
setMessageFragmentationLimit(int) - Method in class org.activemq.ActiveMQConnection
 
setMessageFragmentationLimit(int) - Method in class org.activemq.ActiveMQConnectionFactory
 
setMessageID(String) - Method in class org.activemq.message.MessageAck
 
setMessageID(String) - Method in class org.activemq.service.MessageIdentity
 
setMessageId(String) - Method in class org.activemq.store.journal.JournalAck
 
setMessageListener(MessageListener) - Method in class org.activemq.ActiveMQMessageConsumer
Sets the message consumer's MessageListener.
setMessageListener(MessageListener) - Method in class org.activemq.ActiveMQQueueSession
 
setMessageListener(MessageListener) - Method in class org.activemq.ActiveMQSession
Sets the session's distinguished message listener (optional).
setMessageListener(MessageListener) - Method in class org.activemq.ActiveMQTopicSession
 
setMessageListener(MessageListener) - Method in class org.activemq.pool.PooledSession
 
setMessagePart(boolean) - Method in class org.activemq.message.ActiveMQMessage
 
setMessageRead(boolean) - Method in class org.activemq.message.MessageAck
 
setMessageTableName(String) - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
setMesssageHandle(short) - Method in class org.activemq.message.ActiveMQMessage
 
setMonitorName(String) - Method in class org.activemq.capacity.CapacityMonitorEvent
 
setMsgIdDataType(String) - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
setName(String) - Method in class org.activemq.capacity.BasicCapacityMonitor
 
setName(String) - Method in interface org.activemq.capacity.CapacityMonitor
Set the name of the CapacityMonitor
setName(String) - Method in class org.activemq.capacity.DelegateCapacityMonitor
 
setNetworkChannels(List) - Method in class org.activemq.transport.NetworkConnector
Sets a list of NetworkChannel instances
setNetworkConnectors(List) - Method in interface org.activemq.broker.BrokerContainer
 
setNetworkConnectors(List) - Method in class org.activemq.broker.impl.BrokerContainerImpl
 
setNoDelay(boolean) - Method in class org.activemq.transport.tcp.TcpTransportChannel
 
setNoDelay(boolean) - Method in interface org.activemq.transport.TransportChannel
 
setNoDelay(boolean) - Method in class org.activemq.transport.TransportChannelSupport
 
setNoLocal(boolean) - Method in class org.activemq.message.ConsumerInfo
 
setNoLocal(boolean) - Method in class org.activemq.service.impl.SubscriptionImpl
 
setNoTopicConsumerEnabled(boolean) - Method in class org.activemq.service.DeadLetterPolicy
 
setNumberOfParts(short) - Method in class org.activemq.message.ActiveMQMessage
 
setObject(String, Object) - Method in class org.activemq.message.ActiveMQMapMessage
Sets an object value with the specified name into the Map.
setObject(Serializable) - Method in class org.activemq.message.ActiveMQObjectMessage
Sets the serializable object containing this message's data.
setObjectPayload(Object) - Method in class org.activemq.message.ActiveMQObjectMessage
 
setObjectProperty(String, Object) - Method in class org.activemq.message.ActiveMQMessage
Sets a Java object property value with the specified name into the message.
setOffset(int) - Method in class org.activemq.io.util.ByteArray
 
setOptimizedMessageDispatch(boolean) - Method in class org.activemq.ActiveMQConnection
 
setOptimizedMessageDispatch(boolean) - Method in class org.activemq.ActiveMQConnectionFactory
 
setOrdered(boolean) - Method in class org.activemq.message.ActiveMQDestination
 
setOrderedTarget(String) - Method in class org.activemq.message.ActiveMQDestination
 
setPacketListener(PacketListener) - Method in class org.activemq.transport.composite.CompositeTransportChannel
 
setPacketListener(PacketListener) - Method in interface org.activemq.transport.TransportChannel
Set a listener for Packets
setPacketListener(PacketListener) - Method in class org.activemq.transport.TransportChannelSupport
Set a listener for Packets
setPacketListener(PacketListener) - Method in class org.activemq.transport.vm.VmTransportChannel
 
setParent(CountStatisticImpl) - Method in class org.activemq.management.CountStatisticImpl
 
setParent(CountStatisticImpl, CountStatisticImpl) - Method in class org.activemq.management.JMSEndpointStatsImpl
 
setParent(TimeStatisticImpl, TimeStatisticImpl) - Method in class org.activemq.management.JMSEndpointStatsImpl
 
setParent(TimeStatisticImpl) - Method in class org.activemq.management.TimeStatisticImpl
 
setParentMessageID(String) - Method in class org.activemq.message.ActiveMQMessage
 
setPartNumber(short) - Method in class org.activemq.message.ActiveMQMessage
 
setPassword(String) - Method in class org.activemq.ActiveMQConnectionFactory
 
setPassword(String) - Method in class org.activemq.message.ConnectionInfo
 
setPassword(String) - Method in class org.activemq.util.JmsLogAppender
 
setPassword(String) - Method in class org.activemq.util.JndiJmsLogAppender
 
setPeerURIs(String) - Method in class org.activemq.transport.peer.PeerTransportChannel
 
setPendingMessageCountOnStartup(long) - Method in interface org.activemq.management.JMSDestinationStats
On startup sets the pending message count
setPendingMessageCountOnStartup(long) - Method in class org.activemq.management.JMSQueueStatsImpl
 
setPendingMessageCountOnStartup(long) - Method in class org.activemq.management.JMSTopicStatsImpl
 
setPendingStop(boolean) - Method in interface org.activemq.transport.TransportChannel
Give the TransportChannel a hint it's about to stop
setPendingStop(boolean) - Method in class org.activemq.transport.TransportChannelSupport
Give the TransportChannel a hint it's about to stop
setPersistenceAdapter(PersistenceAdapter) - Method in interface org.activemq.broker.Broker
set the persistence adaptor
setPersistenceAdapter(PersistenceAdapter) - Method in interface org.activemq.broker.BrokerContainer
 
setPersistenceAdapter(PersistenceAdapter) - Method in class org.activemq.broker.impl.BrokerContainerFactoryImpl
 
setPersistenceAdapter(PersistenceAdapter) - Method in class org.activemq.broker.impl.BrokerContainerImpl
 
setPersistenceAdapter(PersistenceAdapter) - Method in class org.activemq.broker.impl.DefaultBroker
 
setPersistent(boolean) - Method in class org.activemq.message.MessageAck
 
setPersistent(boolean) - Method in class org.activemq.transport.peer.PeerTransportChannel
 
setPhysicalName(String) - Method in class org.activemq.message.ActiveMQDestination
 
setPreferedWireFormat(WireFormat) - Method in class org.activemq.io.WireFormatLoader
 
setPrefetchNumber(int) - Method in class org.activemq.ActiveMQMessageConsumer
 
setPrefetchNumber(int) - Method in class org.activemq.message.ConsumerInfo
 
setPrefetchPolicy(ActiveMQPrefetchPolicy) - Method in class org.activemq.ActiveMQConnection
 
setPrefetchPolicy(ActiveMQPrefetchPolicy) - Method in class org.activemq.ActiveMQConnectionFactory
Sets the prefetch policy
setPreparedTransactionStore(TransactionStore) - Method in class org.activemq.broker.impl.DefaultBroker
 
setPrepareMessageBodyOnSend(boolean) - Method in class org.activemq.ActiveMQConnection
Causes pre-serialization of messages before send By default this is on
setPrepareMessageBodyOnSend(boolean) - Method in class org.activemq.ActiveMQConnectionFactory
Causes pre-serialization of messages before send By default this is on
setPriority(int) - Method in class org.activemq.ActiveMQMessageProducer
Sets the producer's default priority.
setPriority(int) - Method in class org.activemq.pool.PooledProducer
 
setProducer(MessageProducer) - Method in class org.activemq.util.JmsLogAppenderSupport
 
setProducerId(short) - Method in class org.activemq.ActiveMQMessageProducer
 
setProducerId(short) - Method in class org.activemq.message.ProducerInfo
 
setProducerKey(String) - Method in class org.activemq.message.ActiveMQMessage
 
setProducerKey(String) - Method in class org.activemq.message.MessageAck
 
setProduceRoles(HashSet) - Method in class org.activemq.security.jassjacc.DestinationSecurityConfig
 
setProperties(Properties) - Method in class org.activemq.jndi.JNDIBaseStorable
set the properties for this instance as retrieved from JNDI
setProperties(Properties) - Method in interface org.activemq.jndi.JNDIStorableInterface
set the properties for this instance as retrieved from JNDI
setProperties(Map) - Method in class org.activemq.message.ActiveMQMessage
Set the Message's properties from an external source No checking on correct types is done by this method
setProperties(Properties) - Method in class org.activemq.message.BrokerInfo
 
setProperties(Properties) - Method in class org.activemq.message.ConnectionInfo
 
setProperties(Object, Map) - Static method in class org.activemq.util.ReflectionSupport
 
setProviderURL(String) - Method in class org.activemq.util.JndiJmsLogAppender
 
setQueueBrowserPrefetch(int) - Method in class org.activemq.ActiveMQPrefetchPolicy
 
setQueuePrefetch(int) - Method in class org.activemq.ActiveMQPrefetchPolicy
 
setQueuePrefix(String) - Method in class org.activemq.jndi.ActiveMQInitialContextFactory
 
setQuickClose(boolean) - Method in class org.activemq.ActiveMQConnection
 
setQuickClose(boolean) - Method in class org.activemq.ActiveMQConnectionFactory
 
setReadOnly(boolean) - Method in class org.activemq.message.ActiveMQMessage
set the message readOnly
setReceipt(Receipt) - Method in class org.activemq.message.ReceiptHolder
Set the Receipt for this holder
setReceiptRequired(boolean) - Method in class org.activemq.message.AbstractPacket
Set if a Recipt if required on receiving this Packet
setReceiptRequired(boolean) - Method in interface org.activemq.message.Packet
Set if a Recipt if required on receiving this Packet
setReceiveCapacity(int) - Method in class org.activemq.transport.vm.VmTransportChannel
 
setReceiveChannel(Channel) - Method in class org.activemq.transport.vm.VmTransportChannel
 
setReconnectSleepTime(long) - Method in class org.activemq.transport.NetworkChannel
 
setRedeliveryPolicy(RedeliveryPolicy) - Method in interface org.activemq.broker.Broker
set the redelivery policy
setRedeliveryPolicy(RedeliveryPolicy) - Method in class org.activemq.broker.impl.BrokerContainerImpl
 
setRedeliveryPolicy(RedeliveryPolicy) - Method in class org.activemq.broker.impl.DefaultBroker
 
setRedeliveryPolicy(RedeliveryPolicy) - Method in class org.activemq.service.impl.SubscriptionImpl
 
setRemote(boolean) - Method in class org.activemq.message.BrokerInfo
 
setRemote(boolean) - Method in class org.activemq.transport.peer.PeerTransportChannel
 
setRemoteBrokerName(String) - Method in class org.activemq.transport.NetworkChannel
 
setRemoteDurableTopicPrefetch(int) - Method in class org.activemq.transport.NetworkConnector
 
setRemoteLocation(String) - Method in class org.activemq.transport.remote.RemoteTransportChannel
 
setRemotePassword(String) - Method in class org.activemq.transport.DiscoveryTransportChannel
 
setRemotePassword(String) - Method in class org.activemq.transport.NetworkChannel
 
setRemotePassword(String) - Method in class org.activemq.transport.NetworkConnector
 
setRemotePassword(String) - Method in class org.activemq.transport.peer.PeerTransportChannel
 
setRemotePassword(String) - Method in class org.activemq.transport.remote.RemoteTransportChannel
 
setRemotePrefetchPolicy(ActiveMQPrefetchPolicy) - Method in class org.activemq.transport.NetworkChannel
 
setRemotePrefetchPolicy(ActiveMQPrefetchPolicy) - Method in class org.activemq.transport.NetworkConnector
 
setRemoteQueueBrowserPrefetch(int) - Method in class org.activemq.transport.NetworkConnector
 
setRemoteQueuePrefetch(int) - Method in class org.activemq.transport.NetworkConnector
 
setRemoteTopicPrefetch(int) - Method in class org.activemq.transport.NetworkConnector
 
setRemoteURI(URI) - Method in class org.activemq.transport.TransportStatusEvent
 
setRemoteUserName(String) - Method in class org.activemq.transport.DiscoveryTransportChannel
 
setRemoteUserName(String) - Method in class org.activemq.transport.NetworkChannel
 
setRemoteUserName(String) - Method in class org.activemq.transport.NetworkConnector
 
setRemoteUserName(String) - Method in class org.activemq.transport.peer.PeerTransportChannel
 
setRemoteUserName(String) - Method in class org.activemq.transport.remote.RemoteTransportChannel
 
setResource(Resource) - Method in class org.activemq.spring.SpringBrokerContainerFactory
 
setResourceName(String) - Method in class org.activemq.message.CapacityInfo
 
setResult(int) - Method in class org.activemq.message.IntResponseReceipt
 
setResult(Serializable) - Method in class org.activemq.message.ResponseReceipt
 
setResultBytes(byte[]) - Method in class org.activemq.message.ResponseReceipt
 
setReuseMessageId(boolean) - Method in class org.activemq.ActiveMQMessageProducer
 
setRight(Expression) - Method in class org.activemq.filter.BinaryExpression
 
setRight(Expression) - Method in class org.activemq.filter.UnaryExpression
 
setRoundingFactor(int) - Method in class org.activemq.capacity.BasicCapacityMonitor
Set the rounding factor (between 1-100)
setRoundingFactor(int) - Method in interface org.activemq.capacity.CapacityMonitor
Set the rounding factor (between 1-100)
setRoundingFactor(int) - Method in class org.activemq.capacity.DelegateCapacityMonitor
Set the rounding factor (between 1-100)
setSecurityAdapter(SecurityAdapter) - Method in interface org.activemq.broker.Broker
Sets the security adapter used to authenticate and authorize access to JMS resources
setSecurityAdapter(SecurityAdapter) - Method in interface org.activemq.broker.BrokerContainer
Sets the security adapter used to authenticate and authorize access to JMS resources
setSecurityAdapter(SecurityAdapter) - Method in class org.activemq.broker.impl.BrokerContainerImpl
 
setSecurityAdapter(SecurityAdapter) - Method in class org.activemq.broker.impl.DefaultBroker
 
setSecurityCredentials(String) - Method in class org.activemq.util.JndiJmsLogAppender
 
setSecurityPrincipalName(String) - Method in class org.activemq.util.JndiJmsLogAppender
 
setSeed(long) - Method in class org.activemq.transport.reliable.SMLCGRandom
Set the seed for the random generator
setSelector(String) - Method in class org.activemq.message.ConsumerInfo
 
setSelector(String) - Method in class org.activemq.service.SubscriberEntry
 
setSendCapacity(int) - Method in class org.activemq.transport.vm.VmTransportChannel
 
setSendChannel(Channel) - Method in class org.activemq.transport.vm.VmTransportChannel
 
setSendCloseTimeout(int) - Method in class org.activemq.ActiveMQConnection
 
setSendConnectionInfoTimeout(int) - Method in class org.activemq.ActiveMQConnection
 
setSendListener(PacketListener) - Method in class org.activemq.transport.vm.VmTransportChannel
 
setSendRoles(HashSet) - Method in class org.activemq.security.jassjacc.DestinationSecurityConfig
 
setSequenceDataType(String) - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
setSequenceNumber(long) - Method in class org.activemq.message.ActiveMQMessage
 
setSequenceNumber(long) - Method in class org.activemq.message.MessageAck
 
setSequenceNumber(Object) - Method in class org.activemq.service.MessageIdentity
 
setServerSide(boolean) - Method in interface org.activemq.transport.TransportChannel
set the server flag
setServerSide(boolean) - Method in class org.activemq.transport.TransportChannelSupport
 
setServiceName(String) - Method in class org.activemq.transport.peer.PeerTransportChannel
 
setSession(Session) - Method in class org.activemq.util.JmsLogAppenderSupport
 
setSessionConsumerDispatchState(int) - Method in class org.activemq.ActiveMQSession
 
setSessionCreatedBy(ActiveMQSession) - Method in class org.activemq.message.ActiveMQDestination
 
setSessionId(short) - Method in class org.activemq.ActiveMQSession
 
setSessionId(short) - Method in class org.activemq.message.CleanupConnectionInfo
 
setSessionId(short) - Method in class org.activemq.message.ConsumerInfo
 
setSessionId(short) - Method in class org.activemq.message.MessageAck
 
setSessionId(short) - Method in class org.activemq.message.ProducerInfo
 
setSessionId(short) - Method in class org.activemq.message.SessionInfo
 
setSessionMode(int) - Method in class org.activemq.message.SessionInfo
 
setShort(String, short) - Method in class org.activemq.message.ActiveMQMapMessage
Sets a short value with the specified name into the Map.
setShortProperty(String, short) - Method in class org.activemq.message.ActiveMQMessage
Sets a short property value with the specified name into the message.
setSocketBufferSize(int) - Method in class org.activemq.transport.tcp.TcpTransportChannel
 
setSoTimeout(int) - Method in class org.activemq.transport.tcp.TcpTransportChannel
set the socket so timeout
setStarted(boolean) - Method in class org.activemq.advisories.TempDestinationAdvisoryEvent
 
setStarted(boolean) - Method in class org.activemq.message.ConnectionInfo
 
setStarted(boolean) - Method in class org.activemq.message.ConsumerInfo
 
setStarted(boolean) - Method in class org.activemq.message.ProducerInfo
 
setStarted(boolean) - Method in class org.activemq.message.SessionInfo
 
setStartTime(long) - Method in class org.activemq.ActiveMQSession
 
setStartTime(long) - Method in class org.activemq.message.BrokerInfo
 
setStartTime(long) - Method in class org.activemq.message.ConnectionInfo
 
setStartTime(long) - Method in class org.activemq.message.ConsumerInfo
 
setStartTime(long) - Method in class org.activemq.message.ProducerInfo
 
setStartTime(long) - Method in class org.activemq.message.SessionInfo
 
setState(byte) - Method in class org.activemq.service.impl.AbstractTransaction
 
setStats(JMSDestinationStats) - Method in class org.activemq.message.ActiveMQDestination
 
setStoreNonPersistentMessages(boolean) - Method in class org.activemq.service.DeadLetterPolicy
 
setString(String, String) - Method in class org.activemq.message.ActiveMQMapMessage
Sets a String value with the specified name into the Map.
setStringIdDataType(String) - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
setStringProperty(String, String) - Method in class org.activemq.message.ActiveMQMessage
Sets a String property value with the specified name into the message.
setSubject(Subject) - Method in interface org.activemq.broker.BrokerClient
Associcates a subject with BrokerClient.
setSubject(Subject) - Method in class org.activemq.broker.impl.BrokerClientImpl
 
setSubscriberEntry(ConsumerInfo, SubscriberEntry) - Method in class org.activemq.store.cache.CacheTopicMessageStore
 
setSubscriberEntry(ConsumerInfo, SubscriberEntry) - Method in class org.activemq.store.jdbc.JDBCTopicMessageStore
 
setSubscriberEntry(ConsumerInfo, SubscriberEntry) - Method in class org.activemq.store.journal.JournalTopicMessageStore
 
setSubscriberEntry(ConsumerInfo, SubscriberEntry) - Method in class org.activemq.store.ProxyTopicMessageStore
 
setSubscriberEntry(ConsumerInfo, SubscriberEntry) - Method in interface org.activemq.store.TopicMessageStore
Inserts or updates the subscriber info due to a subscription change
setSubscriberEntry(ConsumerInfo, SubscriberEntry) - Method in class org.activemq.store.vm.VMTopicMessageStore
 
setSubscriberID(int) - Method in class org.activemq.service.SubscriberEntry
 
setSubscriberName(String) - Method in class org.activemq.message.DurableUnsubscribe
 
setSubscriberName(String) - Method in class org.activemq.service.impl.SubscriptionImpl
 
setSubscription(String) - Method in class org.activemq.store.journal.JournalAck
 
setSubscriptionIdDataType(String) - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
setSupportJMSPriority(boolean) - Method in class org.activemq.io.util.MemoryBoundedObjectManager
 
setTable(Map) - Method in class org.activemq.message.ActiveMQMapMessage
set the table body
setTablePrefix(String) - Method in class org.activemq.store.jdbc.adapter.CachingStatementProvider
 
setTablePrefix(String) - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
setTablePrefix(String) - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
setTablePrefix(String) - Method in interface org.activemq.store.jdbc.StatementProvider
 
setTempDir(File) - Method in class org.activemq.broker.impl.DefaultBroker
 
setText(String) - Method in class org.activemq.message.ActiveMQTextMessage
Sets the string containing this message's data.
setThreadPool(PooledExecutor) - Method in class org.activemq.transport.NetworkChannel
 
setTimeoutCount(int) - Method in class org.activemq.transport.multicast.MulticastDiscoveryAgent
 
setTimeToLive(long) - Method in class org.activemq.ActiveMQMessageProducer
Sets the default length of time in milliseconds from its dispatch time that a produced message should be retained by the message system.
setTimeToLive(long) - Method in class org.activemq.pool.PooledProducer
 
setTimeToLive(int) - Method in class org.activemq.transport.multicast.MulticastDiscoveryAgent
 
setTimeToLive(int) - Method in class org.activemq.transport.multicast.MulticastTransportChannel
 
setTopicPrefetch(int) - Method in class org.activemq.ActiveMQPrefetchPolicy
 
setTopicPrefix(String) - Method in class org.activemq.jndi.ActiveMQInitialContextFactory
 
setTransactionContext(TransactionContext) - Method in class org.activemq.ActiveMQSession
 
setTransactionId(Object) - Method in class org.activemq.message.ActiveMQMessage
 
setTransactionId(Object) - Method in class org.activemq.message.MessageAck
 
setTransactionId(String) - Method in class org.activemq.message.TransactionInfo
 
setTransactionId(Object) - Method in class org.activemq.store.journal.JournalAck
 
setTransactionId(Object) - Method in class org.activemq.store.journal.TxCommand
 
setTransactionIDString(String) - Method in class org.activemq.message.ActiveMQMessage
A helper method for the OpenWire protocol
setTransactionIDString(String) - Method in class org.activemq.message.MessageAck
A helper method for the OpenWire protocol
setTransactionManager(TransactionManager) - Method in class org.activemq.broker.impl.DefaultBroker
 
setTransactionTimeout(int) - Method in class org.activemq.message.XATransactionInfo
 
setTransactionTimeout(int) - Method in class org.activemq.TransactionContext
 
setTransientConsumed(boolean) - Method in class org.activemq.message.ActiveMQMessage
 
setTransportChannel(TransportChannel) - Method in class org.activemq.transport.TransportStatusEvent
 
setTransportChannelListener(TransportChannelListener) - Method in class org.activemq.transport.NetworkConnector
 
setTransportChannelListener(TransportChannelListener) - Method in interface org.activemq.transport.TransportChannel
A listener to be notified when the channel is removed
setTransportChannelListener(TransportChannelListener) - Method in class org.activemq.transport.TransportChannelSupport
 
setTransportChannelListener(TransportChannelListener) - Method in interface org.activemq.transport.TransportServerChannel
Registers the listener to be used when new clients connect or disconnect
setTransportChannelListener(TransportChannelListener) - Method in class org.activemq.transport.TransportServerChannelSupport
 
setTransportConnected(boolean) - Method in class org.activemq.transport.TransportChannelSupport
 
setTransportConnectors(List) - Method in interface org.activemq.broker.BrokerContainer
 
setTransportConnectors(List) - Method in class org.activemq.broker.impl.BrokerContainerImpl
 
setTransportDataIn(DataInputStream) - Method in class org.activemq.io.AbstractWireFormat
 
setTransportDataOut(DataOutputStream) - Method in class org.activemq.io.AbstractWireFormat
 
setTurboBoost(boolean) - Method in class org.activemq.ActiveMQConnectionFactory
Set this flag for fast throughput!
setTxTableName(String) - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
setType(int) - Method in class org.activemq.message.TransactionInfo
 
setType(int) - Method in class org.activemq.message.XATransactionInfo
 
setType(byte) - Method in class org.activemq.store.journal.TxCommand
 
setUri(URI) - Method in class org.activemq.transport.multicast.MulticastDiscoveryAgent
 
setUri(URI) - Method in class org.activemq.transport.multicast.MulticastTester
 
setUri(String) - Method in class org.activemq.transport.NetworkChannel
set the uri of the broker(s) this channel is connected to
setUri(String) - Method in class org.activemq.util.JmsLogAppender
 
setUris(List) - Method in class org.activemq.transport.composite.CompositeTransportChannel
 
setUrl(String) - Method in class org.activemq.transport.TransportServerChannelSupport
 
setUrlPkgPrefixes(String) - Method in class org.activemq.util.JndiJmsLogAppender
 
setUseAsyncSend(boolean) - Method in class org.activemq.ActiveMQConnection
 
setUseAsyncSend(boolean) - Method in class org.activemq.ActiveMQConnectionFactory
 
setUseAsyncSend(boolean) - Method in class org.activemq.transport.tcp.TcpTransportChannel
set the useAsync flag
setUseAsyncSend(boolean) - Method in class org.activemq.transport.tcp.TcpTransportServerChannel
 
setUseDatabaseLocking(boolean) - Method in class org.activemq.service.DeadLetterPolicy
 
setUsedInternally(boolean) - Method in interface org.activemq.transport.TransportChannel
 
setUsedInternally(boolean) - Method in class org.activemq.transport.TransportChannelSupport
 
setUseEmbeddedBroker(boolean) - Method in class org.activemq.ActiveMQConnectionFactory
Allows embedded brokers to be associated with a connection factory
setUserName(String) - Method in class org.activemq.ActiveMQConnectionFactory
 
setUserName(String) - Method in class org.activemq.message.ConnectionInfo
 
setUserName(String) - Method in class org.activemq.util.JmsLogAppender
 
setUserName(String) - Method in class org.activemq.util.JndiJmsLogAppender
 
setValue(Object) - Method in class org.activemq.message.CachedValue
 
setValueLimit(long) - Method in class org.activemq.capacity.BasicCapacityMonitor
set a new value limit for the CapacityMonitor
setValueLimit(long) - Method in interface org.activemq.capacity.CapacityMonitor
set a new value limit for the CapacityMonitor
setValueLimit(long) - Method in class org.activemq.capacity.DelegateCapacityMonitor
set a new value limit for the CapacityMonitor
setVersion(int) - Method in class org.activemq.message.WireFormatInfo
 
setWasPrepared(boolean) - Method in class org.activemq.store.journal.TxCommand
 
setWireFormat(WireFormat) - Method in class org.activemq.ActiveMQConnectionFactory
Allows a custom wire format to be used; otherwise the default Java wire format is used which is designed for minimum size and maximum speed on the Java platform
setWireFormat(String) - Method in class org.activemq.ActiveMQConnectionFactory
set the WireFormat by name - e.g.
setWireFormat(WireFormat) - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
setWireFormat(WireFormat) - Method in class org.activemq.transport.peer.PeerTransportChannel
 
setWireFormat(WireFormat) - Method in class org.activemq.transport.remote.RemoteTransportChannel
 
setWireFormat(WireFormat) - Method in class org.activemq.transport.tcp.TcpTransportServerChannel
 
setWireFormat(WireFormat) - Method in interface org.activemq.transport.TransportChannel
set the wire format to be used by this channel
setWireFormat(WireFormat) - Method in class org.activemq.transport.TransportChannelSupport
set the wire format to be used by this channel
setWireFormatVersion(int) - Method in class org.activemq.io.impl.AbstractPacketMarshaller
Set the wire format version
setWireFormatVersion(int) - Method in class org.activemq.io.impl.AbstractPacketReader
Set the wire format version
setWireFormatVersion(int) - Method in class org.activemq.io.impl.AbstractPacketWriter
Set the wire format version
setWireFormatVersion(int) - Method in interface org.activemq.io.impl.PacketReader
Set the wire format version
setWireFormatVersion(int) - Method in interface org.activemq.io.impl.PacketWriter
Set the wire format version
setWireFormatVersion(int) - Method in class org.activemq.message.ConnectionInfo
 
setWriter(PrintWriter) - Method in class org.activemq.transport.jabber.JabberWireFormat
 
setXid(ActiveMQXid) - Method in class org.activemq.message.XATransactionInfo
 
setXidDataType(String) - Method in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
SfTransportChannelFactory - Class in org.activemq.transport.tcp
A factory of TcpTransportChannelFactory instances using a SocketFactory
SfTransportChannelFactory(SocketFactory) - Constructor for class org.activemq.transport.tcp.SfTransportChannelFactory
 
SfTransportServerChannelFactory - Class in org.activemq.transport.tcp
An implementation of TransportServerChannelFactory which uses a ServerSocketFactory to create ServerSocket instances
SfTransportServerChannelFactory(ServerSocketFactory) - Constructor for class org.activemq.transport.tcp.SfTransportServerChannelFactory
 
shallowCopy() - Method in class org.activemq.message.ActiveMQBytesMessage
 
shallowCopy() - Method in class org.activemq.message.ActiveMQMapMessage
 
shallowCopy() - Method in class org.activemq.message.ActiveMQMessage
 
shallowCopy() - Method in class org.activemq.message.ActiveMQObjectMessage
 
shallowCopy() - Method in class org.activemq.message.ActiveMQStreamMessage
 
shallowCopy() - Method in class org.activemq.message.ActiveMQTextMessage
 
SHUTDOWN_SERVER_VM - Static variable in class org.activemq.message.BrokerAdminCommand
 
SimpleCachePersistenceAdapter - Class in org.activemq.store.cache
Provides a CachePersistenceAdapter that uses a seperate LRU cache for each destination.
SimpleCachePersistenceAdapter() - Constructor for class org.activemq.store.cache.SimpleCachePersistenceAdapter
 
SimpleCachePersistenceAdapter(PersistenceAdapter) - Constructor for class org.activemq.store.cache.SimpleCachePersistenceAdapter
 
SimpleCharStream - Class in org.activemq.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.activemq.selector.SimpleCharStream
 
SimpleCharStream(Reader, int, int) - Constructor for class org.activemq.selector.SimpleCharStream
 
SimpleCharStream(Reader) - Constructor for class org.activemq.selector.SimpleCharStream
 
SimpleCharStream(InputStream, int, int, int) - Constructor for class org.activemq.selector.SimpleCharStream
 
SimpleCharStream(InputStream, int, int) - Constructor for class org.activemq.selector.SimpleCharStream
 
SimpleCharStream(InputStream) - Constructor for class org.activemq.selector.SimpleCharStream
 
SimpleDestinationFilter - Class in org.activemq.filter
Matches messages sent to an exact destination
SimpleDestinationFilter(Destination) - Constructor for class org.activemq.filter.SimpleDestinationFilter
 
SimpleMessageCache - Class in org.activemq.store.cache
A simple cache that stores messages in memory.
SimpleMessageCache() - Constructor for class org.activemq.store.cache.SimpleMessageCache
 
SimpleMessageCache(int) - Constructor for class org.activemq.store.cache.SimpleMessageCache
 
size() - Method in class org.activemq.ActiveMQMessageConsumer
 
size() - Method in class org.activemq.io.util.MemoryBoundedPrioritizedQueue
 
size() - Method in class org.activemq.io.util.MemoryBoundedQueue
 
size() - Method in class org.activemq.io.util.SpooledBoundedActiveMQMessageQueue
 
size() - Method in class org.activemq.service.impl.DefaultQueueList
 
size - Variable in class org.activemq.service.impl.QueueListSupport.Header
 
size() - Method in class org.activemq.service.impl.QueueListSupport
 
size() - Method in interface org.activemq.service.QueueList
Returns the number of elements in this list.
skip(long) - Method in class org.activemq.streams.JMSInputStream
Skip n bytes in this stream; returns the number of bytes actually skipped (which may be less than the number requested).
SMLCGRandom - Class in org.activemq.transport.reliable
A Shuffled Multiple Combined Linear Congruential Generator Uses L'Ecuyer's CLCG4 with a Bays-Durham shuffle.
SMLCGRandom() - Constructor for class org.activemq.transport.reliable.SMLCGRandom
Creates a new pseudorandom number generator, seeded from the current time.
SMLCGRandom(long) - Constructor for class org.activemq.transport.reliable.SMLCGRandom
Creates the generator with the provided seed
socket - Variable in class org.activemq.transport.tcp.TcpTransportChannel
 
socket - Variable in class org.activemq.transport.udp.UdpTransportChannel
 
specialConstructor - Variable in exception org.activemq.selector.ParseException
This variable determines which constructor was used to create this object and thereby affects the semantics of the "getMessage" method (see below).
specialToken - Variable in class org.activemq.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.
SpooledBoundedActiveMQMessageQueue - Class in org.activemq.io.util
Implements a controlled thread safe queue, with ActiveMQMessages being spooled to disk for reading asynchronously.
SpooledBoundedActiveMQMessageQueue(File, String, long, int) - Constructor for class org.activemq.io.util.SpooledBoundedActiveMQMessageQueue
Constructor for SpooledBoundedActiveMQMessageQueue
SpooledBoundedActiveMQMessageQueue(File, String) - Constructor for class org.activemq.io.util.SpooledBoundedActiveMQMessageQueue
Constructor for SpooledBoundedActiveMQMessageQueue
SPRING_CLASS_NAME - Static variable in class org.activemq.XmlConfigHelper
 
SpringBrokerContainerFactory - Class in org.activemq.spring
A Spring implementatation of BrokerContainerFactory which uses an XML deployment configuration file to load and configure a BrokerContainer
SpringBrokerContainerFactory() - Constructor for class org.activemq.spring.SpringBrokerContainerFactory
 
SpringBrokerContainerFactory(Resource) - Constructor for class org.activemq.spring.SpringBrokerContainerFactory
 
start() - Method in class org.activemq.ActiveMQConnection
Starts (or restarts) a connection's delivery of incoming messages.
start() - Method in class org.activemq.ActiveMQConnectionFactory
 
start() - Method in class org.activemq.ActiveMQMessageConsumer
 
start() - Method in class org.activemq.ActiveMQSession
Start this Session
start() - Method in class org.activemq.advisories.ConnectionAdvisor
start listening for advisories
start() - Method in class org.activemq.advisories.ConsumerAdvisor
start listening for advisories
start() - Method in class org.activemq.advisories.ProducerAdvisor
start listening for advisories
start() - Method in class org.activemq.advisories.ProducerDemandAdvisor
 
start() - Method in class org.activemq.advisories.TempDestinationAdvisor
start listening for advisories
start() - Method in class org.activemq.broker.impl.BrokerClientImpl
start consuming messages
start() - Method in class org.activemq.broker.impl.BrokerConnectorImpl
start the Broker
start() - Method in class org.activemq.broker.impl.BrokerContainerImpl
start the Container
start() - Method in class org.activemq.broker.impl.DefaultBroker
Start this Service
start() - Method in class org.activemq.io.util.MemoryBoundedQueue
enable dequeueing
start() - Method in class org.activemq.io.util.SpooledBoundedActiveMQMessageQueue
enable dequeueing
START - Static variable in interface org.activemq.message.TransactionType
Start a transaction
start() - Method in class org.activemq.pool.PooledConnection
 
start() - Method in class org.activemq.pool.PooledConnectionFactory
 
start() - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageContainer
start working
start() - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageManager
start the manager
start() - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
start working
start() - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageManager
start the manager
start() - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
start working
start() - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageManager
start the manager
start() - Method in class org.activemq.service.impl.DispatcherImpl
start the DispatchWorker
start() - Method in class org.activemq.service.impl.DispatchWorker
start the DispatchWorker
start() - Method in class org.activemq.service.impl.DurableQueueMessageContainer
 
start() - Method in class org.activemq.service.impl.DurableTopicMessageContainer
 
start() - Method in class org.activemq.service.impl.MessageContainerManagerSupport
 
start() - Method in class org.activemq.service.impl.ProxyMessageContainerManager
 
start() - Method in class org.activemq.service.impl.TransactionManagerImpl
 
start() - Method in interface org.activemq.service.QueueMessageContainer
This container has just been loaded from disk and so it needs to be recovered, that is iterate through all the message IDs in the persistent store and add them to the in memory list of message IDs to be dispatched by consumers
start() - Method in interface org.activemq.service.Service
Called to start the service
start() - Method in class org.activemq.store.cache.CacheMessageStore
 
start() - Method in class org.activemq.store.cache.CachePersistenceAdapter
 
start() - Method in class org.activemq.store.jdbc.JDBCMessageStore
 
start() - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
start() - Method in class org.activemq.store.journal.JournalMessageStore
 
start() - Method in class org.activemq.store.journal.JournalPersistenceAdapter
 
start() - Method in class org.activemq.store.journal.JournalTransactionStore
 
start() - Method in class org.activemq.store.ProxyMessageStore
 
start() - Method in class org.activemq.store.ProxyTopicMessageStore
 
start() - Method in class org.activemq.store.vm.VMMessageStore
 
start() - Method in class org.activemq.store.vm.VMPersistenceAdapter
 
start() - Method in class org.activemq.store.vm.VMTransactionStore
 
start(Xid, int) - Method in class org.activemq.TransactionContext
Associates a transaction with the resource.
start() - Method in class org.activemq.transport.activeio.ActiveIOTransportChannel
 
start() - Method in class org.activemq.transport.activeio.ActiveIOTransportServerChannel
 
start() - Method in class org.activemq.transport.composite.CompositeTransportChannel
 
start() - Method in class org.activemq.transport.DiscoveryNetworkConnector
 
start() - Method in class org.activemq.transport.DiscoveryTransportChannel
 
start() - Method in class org.activemq.transport.multicast.MulticastDiscoveryAgent
start this discovery agent
start() - Method in class org.activemq.transport.multicast.MulticastTester
 
start() - Method in class org.activemq.transport.multicast.MulticastTransportServerChannel
start listeneing for events
start() - Method in class org.activemq.transport.NetworkChannel
Start the channel
start() - Method in class org.activemq.transport.NetworkConnector
 
start() - Method in class org.activemq.transport.reliable.KeepAliveDaemon
 
start() - Method in class org.activemq.transport.tcp.TcpTransportChannel
start listeneing for events
start() - Method in class org.activemq.transport.tcp.TcpTransportServerChannel
 
start() - Method in interface org.activemq.transport.TransportChannel
start listeneing for events
start() - Method in interface org.activemq.transport.TransportServerChannel
start listeneing for events
start() - Method in class org.activemq.transport.TransportServerChannelSupport
 
start() - Method in class org.activemq.transport.udp.UdpTransportChannel
start listeneing for events
start() - Method in class org.activemq.transport.udp.UdpTransportServerChannel
start listeneing for events
start() - Method in class org.activemq.transport.vm.VmTransportChannel
 
start() - Method in class org.activemq.transport.vm.VmTransportServerChannel
start listeneing for events
START_STATE - Static variable in class org.activemq.service.impl.AbstractTransaction
 
startAdvisoryForTempDestination(Destination) - Method in class org.activemq.ActiveMQConnection
 
started - Variable in class org.activemq.transport.composite.CompositeTransportChannel
 
startRunning() - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
 
startTemporaryDestination(ActiveMQDestination) - Method in class org.activemq.ActiveMQConnection
 
startTime - Variable in class org.activemq.ActiveMQMessageConsumer
 
startTransaction(BrokerClient, String) - Method in interface org.activemq.broker.Broker
start a transaction
startTransaction(BrokerClient, ActiveMQXid) - Method in interface org.activemq.broker.Broker
 
startTransaction(BrokerClient, String) - Method in interface org.activemq.broker.BrokerConnector
Start a transaction from the Client session
startTransaction(BrokerClient, ActiveMQXid) - Method in interface org.activemq.broker.BrokerConnector
Start an XA transaction
startTransaction(BrokerClient, String) - Method in interface org.activemq.broker.BrokerContainer
Start a transaction from the Client session
startTransaction(BrokerClient, ActiveMQXid) - Method in interface org.activemq.broker.BrokerContainer
Start an XA transaction.
startTransaction(BrokerClient, String) - Method in class org.activemq.broker.impl.BrokerConnectorImpl
Start a transaction from the Client session
startTransaction(BrokerClient, ActiveMQXid) - Method in class org.activemq.broker.impl.BrokerConnectorImpl
Start an XA transaction.
startTransaction(BrokerClient, String) - Method in class org.activemq.broker.impl.BrokerContainerImpl
Start a transaction from the Client session
startTransaction(BrokerClient, ActiveMQXid) - Method in class org.activemq.broker.impl.BrokerContainerImpl
Start an XA transaction.
startTransaction(BrokerClient, String) - Method in class org.activemq.broker.impl.DefaultBroker
Start a transaction.
startTransaction(BrokerClient, ActiveMQXid) - Method in class org.activemq.broker.impl.DefaultBroker
Starts an XA Transaction.
StatelessDefaultWireFormat - Class in org.activemq.io.impl
Provides a stateless implementation of AbstractDefaultWireFormat.
StatelessDefaultWireFormat() - Constructor for class org.activemq.io.impl.StatelessDefaultWireFormat
 
statementProvider - Variable in class org.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
StatementProvider - Interface in org.activemq.store.jdbc
Generates the SQL statements that are used by the JDBCAdapter.
staticFlag - Static variable in class org.activemq.selector.SimpleCharStream
 
StatisticImpl - Class in org.activemq.management
Base class for a Statistic implementation
StatisticImpl(String, String, String) - Constructor for class org.activemq.management.StatisticImpl
 
StatsCapable - Interface in org.activemq.management
Represents an object which is capable of providing some stats
StatsImpl - Class in org.activemq.management
Base class for a Stats implementation
StatsImpl() - Constructor for class org.activemq.management.StatsImpl
 
StatsImpl(Map) - Constructor for class org.activemq.management.StatsImpl
 
statusChanged(TransportStatusEvent) - Method in class org.activemq.ActiveMQConnection
handle disconnect/reconnect events
statusChanged(TransportStatusEvent) - Method in class org.activemq.transport.composite.CompositeTransportChannel
 
statusChanged(TransportStatusEvent) - Method in class org.activemq.transport.NetworkChannel
 
statusChanged(TransportStatusEvent) - Method in class org.activemq.transport.RemoteNetworkChannel
 
statusChanged(TransportStatusEvent) - Method in interface org.activemq.transport.TransportStatusEventListener
called when the status of a transport channel changes
Stomp - Interface in org.activemq.transport.stomp
 
Stomp.Commands - Interface in org.activemq.transport.stomp
 
Stomp.Headers - Interface in org.activemq.transport.stomp
 
Stomp.Headers.Ack - Interface in org.activemq.transport.stomp
 
Stomp.Headers.Connect - Interface in org.activemq.transport.stomp
 
Stomp.Headers.Connected - Interface in org.activemq.transport.stomp
 
Stomp.Headers.Error - Interface in org.activemq.transport.stomp
 
Stomp.Headers.Message - Interface in org.activemq.transport.stomp
 
Stomp.Headers.Receipt - Interface in org.activemq.transport.stomp
 
Stomp.Headers.Send - Interface in org.activemq.transport.stomp
 
Stomp.Headers.Subscribe - Interface in org.activemq.transport.stomp
 
Stomp.Headers.Subscribe.AckModeValues - Interface in org.activemq.transport.stomp
 
Stomp.Headers.Unsubscribe - Interface in org.activemq.transport.stomp
 
Stomp.Responses - Interface in org.activemq.transport.stomp
 
StompTransportChannel - Class in org.activemq.transport.stomp
A transport for using Stomp to talk to ActiveMQ
StompTransportChannel() - Constructor for class org.activemq.transport.stomp.StompTransportChannel
 
StompTransportChannel(URI) - Constructor for class org.activemq.transport.stomp.StompTransportChannel
 
StompTransportChannel(URI, URI) - Constructor for class org.activemq.transport.stomp.StompTransportChannel
 
StompTransportChannel(TcpTransportServerChannel, Socket, Executor) - Constructor for class org.activemq.transport.stomp.StompTransportChannel
 
StompTransportChannel(Socket, Executor) - Constructor for class org.activemq.transport.stomp.StompTransportChannel
 
StompTransportChannelFactory - Class in org.activemq.transport.stomp
A TTMP transport factory
StompTransportChannelFactory() - Constructor for class org.activemq.transport.stomp.StompTransportChannelFactory
 
StompTransportServerChannel - Class in org.activemq.transport.stomp
A TTMP server connector
StompTransportServerChannel(URI) - Constructor for class org.activemq.transport.stomp.StompTransportServerChannel
 
StompTransportServerChannel(ServerSocket) - Constructor for class org.activemq.transport.stomp.StompTransportServerChannel
 
StompTransportServerChannelFactory - Class in org.activemq.transport.stomp
A TTMP transport factory
StompTransportServerChannelFactory() - Constructor for class org.activemq.transport.stomp.StompTransportServerChannelFactory
 
StompWireFormat - Class in org.activemq.transport.stomp
Implements the TTMP protocol.
StompWireFormat() - Constructor for class org.activemq.transport.stomp.StompWireFormat
 
stop() - Method in class org.activemq.ActiveMQConnection
Temporarily stops a connection's delivery of incoming messages.
stop() - Method in class org.activemq.ActiveMQConnectionFactory
A hook to allow any embedded JMS Broker's to be closed down
stop() - Method in class org.activemq.ActiveMQMessageConsumer
 
stop() - Method in class org.activemq.ActiveMQSession
Stop this Session
stop() - Method in class org.activemq.advisories.ConnectionAdvisor
stop listening for advisories
stop() - Method in class org.activemq.advisories.ConsumerAdvisor
stop listening for advisories
stop() - Method in class org.activemq.advisories.ProducerAdvisor
stop listening for advisories
stop() - Method in class org.activemq.advisories.ProducerDemandAdvisor
 
stop() - Method in class org.activemq.advisories.TempDestinationAdvisor
stop listening for advisories
stop() - Method in class org.activemq.broker.impl.BrokerClientImpl
stop consuming messages
stop() - Method in class org.activemq.broker.impl.BrokerConnectorImpl
Stop the Broker
stop() - Method in class org.activemq.broker.impl.BrokerContainerImpl
Stop the Container
stop() - Method in class org.activemq.broker.impl.DefaultBroker
stop this Service
stop() - Method in class org.activemq.io.util.MemoryBoundedQueue
disable dequeueing
stop() - Method in class org.activemq.io.util.SpooledBoundedActiveMQMessageQueue
disable dequeueing
stop() - Method in class org.activemq.pool.PooledConnection
 
stop() - Method in class org.activemq.pool.PooledConnectionFactory
 
stop() - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageContainer
stop working
stop() - Method in class org.activemq.service.boundedvm.DurableQueueBoundedMessageManager
stop the manager
stop() - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
stop working
stop() - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageManager
stop the manager
stop() - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
stop working
stop() - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageManager
stop the manager
stop() - Method in class org.activemq.service.impl.DispatcherImpl
stop the DispatchWorker
stop() - Method in class org.activemq.service.impl.DispatchWorker
stop the DispatchWorker
stop() - Method in class org.activemq.service.impl.DurableQueueMessageContainer
 
stop() - Method in class org.activemq.service.impl.DurableTopicMessageContainer
 
stop() - Method in class org.activemq.service.impl.MessageContainerManagerSupport
 
stop() - Method in class org.activemq.service.impl.ProxyMessageContainerManager
 
stop() - Method in class org.activemq.service.impl.TransactionManagerImpl
 
stop() - Method in interface org.activemq.service.Service
Called to shutdown the service
stop() - Method in class org.activemq.store.cache.CacheMessageStore
 
stop() - Method in class org.activemq.store.cache.CachePersistenceAdapter
 
stop() - Method in class org.activemq.store.jdbc.JDBCMessageStore
 
stop() - Method in class org.activemq.store.jdbc.JDBCPersistenceAdapter
 
stop() - Method in class org.activemq.store.journal.JournalMessageStore
 
stop() - Method in class org.activemq.store.journal.JournalPersistenceAdapter
 
stop() - Method in class org.activemq.store.journal.JournalTransactionStore
 
stop() - Method in class org.activemq.store.ProxyMessageStore
 
stop() - Method in class org.activemq.store.ProxyTopicMessageStore
 
stop() - Method in class org.activemq.store.vm.VMMessageStore
 
stop() - Method in class org.activemq.store.vm.VMPersistenceAdapter
 
stop() - Method in class org.activemq.store.vm.VMTopicMessageStore
 
stop() - Method in class org.activemq.store.vm.VMTransactionStore
 
stop() - Method in class org.activemq.transport.activeio.ActiveIOTransportChannel
 
stop() - Method in class org.activemq.transport.activeio.ActiveIOTransportServerChannel
 
stop() - Method in class org.activemq.transport.composite.CompositeTransportChannel
close the channel
stop() - Method in class org.activemq.transport.DiscoveryTransportChannel
 
stop() - Method in class org.activemq.transport.multicast.MulticastDiscoveryAgent
stop this discovery agent
stop() - Method in class org.activemq.transport.multicast.MulticastTester
 
stop() - Method in class org.activemq.transport.NetworkChannel
stop the channel
stop() - Method in class org.activemq.transport.NetworkConnector
 
stop() - Method in class org.activemq.transport.reliable.KeepAliveDaemon
 
stop() - Method in class org.activemq.transport.reliable.ReliableTransportChannel
stop this channel
stop() - Method in class org.activemq.transport.remote.RemoteTransportChannel
 
stop() - Method in class org.activemq.transport.tcp.TcpTransportChannel
close the channel
stop() - Method in class org.activemq.transport.tcp.TcpTransportServerChannel
 
stop() - Method in interface org.activemq.transport.TransportChannel
close the channel
stop() - Method in class org.activemq.transport.TransportChannelSupport
close the channel
stop() - Method in interface org.activemq.transport.TransportServerChannel
close the ServerChannel
stop() - Method in class org.activemq.transport.TransportServerChannelSupport
 
stop() - Method in class org.activemq.transport.udp.UdpTransportChannel
close the channel
stop() - Method in class org.activemq.transport.vm.VmTransportChannel
 
stopAdvisoryForTempDestination(ActiveMQDestination) - Method in class org.activemq.ActiveMQConnection
 
stopExecutor(Executor) - Method in class org.activemq.transport.TransportChannelSupport
A helper method to stop the execution of an executor
stopExecutor(Executor) - Static method in class org.activemq.util.ExecutorHelper
A helper method to stop the execution of an executor
stopped - Variable in class org.activemq.io.util.MemoryBoundedQueue
 
STOPPED - Static variable in class org.activemq.transport.TransportStatusEvent
The channel has been STOPPED
stopTemporaryDestination(ActiveMQDestination) - Method in class org.activemq.ActiveMQConnection
 
store - Variable in class org.activemq.store.journal.JournalTransactionStore.TxOperation
 
storeSubscription(ConsumerInfo, Subscription) - Method in class org.activemq.service.impl.DurableTopicMessageContainer
 
storeSubscription(ConsumerInfo, Subscription) - Method in interface org.activemq.service.TopicMessageContainer
Stores the persistence details in the database
StreamJDBCAdapter - Class in org.activemq.store.jdbc.adapter
This JDBCAdapter inserts and extracts BLOB data using the setBinaryStream()/getBinaryStream() operations.
StreamJDBCAdapter() - Constructor for class org.activemq.store.jdbc.adapter.StreamJDBCAdapter
 
StreamJDBCAdapter(StatementProvider) - Constructor for class org.activemq.store.jdbc.adapter.StreamJDBCAdapter
 
streamMessageReader - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
streamMessageWriter - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
STRING_LITERAL - Static variable in interface org.activemq.selector.SelectorParserConstants
 
stringIdDataType - Variable in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
stringLitteral() - Method in class org.activemq.selector.SelectorParser
 
stripLeadingSlashes(String) - Static method in class org.activemq.transport.composite.CompositeTransportChannelFactory
 
SUBSCRIBE - Static variable in interface org.activemq.transport.stomp.Stomp.Commands
 
SubscriberEntry - Class in org.activemq.service
Represents a durable subscribers subscription entry which contains details of the subscription and the subscriber's unique ID
SubscriberEntry() - Constructor for class org.activemq.service.SubscriberEntry
 
Subscription - Interface in org.activemq.service
A Subscription holds messages to be dispatched to a a Client Consumer
SUBSCRIPTION - Static variable in interface org.activemq.transport.stomp.Stomp.Headers.Message
 
subscriptionContainer - Variable in class org.activemq.service.impl.DurableQueueMessageContainerManager
 
subscriptionContainer - Variable in class org.activemq.service.impl.DurableTopicMessageContainerManager
 
SubscriptionContainer - Interface in org.activemq.service
Represents a possibly persistent container of subscription objects
SubscriptionContainerImpl - Class in org.activemq.service.impl
A default RAM only implementation of the SubscriptionContainer
SubscriptionContainerImpl(RedeliveryPolicy, DeadLetterPolicy) - Constructor for class org.activemq.service.impl.SubscriptionContainerImpl
 
SubscriptionContainerImpl(Map, RedeliveryPolicy, DeadLetterPolicy) - Constructor for class org.activemq.service.impl.SubscriptionContainerImpl
 
subscriptionIdDataType - Variable in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
SubscriptionImpl - Class in org.activemq.service.impl
A Subscription holds messages to be dispatched to a a Client Consumer
SubscriptionImpl(Dispatcher, BrokerClient, ConsumerInfo, Filter, RedeliveryPolicy, DeadLetterPolicy) - Constructor for class org.activemq.service.impl.SubscriptionImpl
Create a Subscription object that holds messages to be dispatched to a Consumer
subscriptionIterator() - Method in class org.activemq.service.impl.SubscriptionContainerImpl
 
subscriptionIterator() - Method in interface org.activemq.service.SubscriptionContainer
 
subtract(long) - Method in class org.activemq.management.CountStatisticImpl
 
SwitchTo(int) - Method in class org.activemq.selector.SelectorParserTokenManager
 
syncSendPacket(Packet) - Method in class org.activemq.ActiveMQConnection
send a Packet through a Connection - for internal use only
syncSendPacket(Packet, int) - Method in class org.activemq.ActiveMQConnection
Send a packet through a Connection - for internal use only
syncSendRequest(Packet) - Method in class org.activemq.ActiveMQConnection
 
SystemProperties - Class in org.activemq.util
Helper class for accessing System properties
SystemProperties() - Constructor for class org.activemq.util.SystemProperties
 

T

tablePrefix - Variable in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
tailKey - Variable in class org.activemq.service.impl.QueueListSupport.Header
 
targetAndDispatch(BrokerClient, ActiveMQMessage) - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
See if this container should get this message and dispatch it
TcpBufferedOutputStream - Class in org.activemq.transport.tcp
An optimized buffered outputstream for Tcp
TcpBufferedOutputStream(OutputStream) - Constructor for class org.activemq.transport.tcp.TcpBufferedOutputStream
Constructor
TcpBufferedOutputStream(OutputStream, int) - Constructor for class org.activemq.transport.tcp.TcpBufferedOutputStream
Creates a new buffered output stream to write data to the specified underlying output stream with the specified buffer size.
TcpTransportChannel - Class in org.activemq.transport.tcp
A tcp implementation of a TransportChannel
TcpTransportChannel(WireFormat) - Constructor for class org.activemq.transport.tcp.TcpTransportChannel
Construct basic helpers
TcpTransportChannel(WireFormat, URI) - Constructor for class org.activemq.transport.tcp.TcpTransportChannel
Connect to a remote Node - e.g.
TcpTransportChannel(WireFormat, URI, URI) - Constructor for class org.activemq.transport.tcp.TcpTransportChannel
Connect to a remote Node - e.g.
TcpTransportChannel(TcpTransportServerChannel, WireFormat, Socket, Executor) - Constructor for class org.activemq.transport.tcp.TcpTransportChannel
Initialize from a ServerSocket
TcpTransportChannel(WireFormat, Socket, Executor) - Constructor for class org.activemq.transport.tcp.TcpTransportChannel
 
TcpTransportChannelFactory - Class in org.activemq.transport.tcp
A tcp implementation of a TransportChannelFactory
TcpTransportChannelFactory() - Constructor for class org.activemq.transport.tcp.TcpTransportChannelFactory
 
TcpTransportServerChannel - Class in org.activemq.transport.tcp
Binds to a well known port and listens for Sockets ...
TcpTransportServerChannel(WireFormat, URI) - Constructor for class org.activemq.transport.tcp.TcpTransportServerChannel
Default Constructor
TcpTransportServerChannel(WireFormat, ServerSocket) - Constructor for class org.activemq.transport.tcp.TcpTransportServerChannel
 
TcpTransportServerChannelFactory - Class in org.activemq.transport.tcp
A tcp implementation of a TransportServerChannelFactory
TcpTransportServerChannelFactory() - Constructor for class org.activemq.transport.tcp.TcpTransportServerChannelFactory
 
TEMP_DESTINATION_ADVISORY_PREFIX - Static variable in class org.activemq.message.ActiveMQDestination
Deprecated. Use #getDestinationForTempAdvisory() instead.
TempDestinationAdvisor - Class in org.activemq.advisories
A helper class for listening for TempDestination advisories
TempDestinationAdvisor(Connection, Destination) - Constructor for class org.activemq.advisories.TempDestinationAdvisor
Construct a TempDestinationAdvisor
TempDestinationAdvisoryEvent - Class in org.activemq.advisories
This event is raised when a MessageTempDestination starts/stops *
TempDestinationAdvisoryEvent() - Constructor for class org.activemq.advisories.TempDestinationAdvisoryEvent
Empty constructor
TempDestinationAdvisoryEvent(ActiveMQDestination, boolean) - Constructor for class org.activemq.advisories.TempDestinationAdvisoryEvent
Default Constructor
TempDestinationAdvisoryEventListener - Interface in org.activemq.advisories
A Listener for TempDestinationAdvisoryEvents * @version $Revision: 1.1.1.1 $
terminateBrokerVM() - Method in class org.activemq.ActiveMQConnection
Tells the broker to terminate its VM.
TestingConsumer - Class in org.activemq.spring
A simple consumer which is useful for testing which can be used to wait until the consumer has received a specific number of messages.
TestingConsumer() - Constructor for class org.activemq.spring.TestingConsumer
 
TestingConsumer(Object) - Constructor for class org.activemq.spring.TestingConsumer
 
textMessageReader - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
textMessageWriter - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
TextWireFormat - Class in org.activemq.io
Represents a text based WireFormat such as one that uses XML packets like the org.activemq.transport.xstream.XStreamWireFormat or the JabberWireFormat
TextWireFormat() - Constructor for class org.activemq.io.TextWireFormat
 
threadPool - Variable in class org.activemq.transport.NetworkChannel
 
threadPool - Variable in class org.activemq.transport.NetworkConnector
 
throwJMSException() - Method in class org.activemq.util.ExceptionTemplate
Throws the first exception caught during the execution of this template as a JMS exception or do nothing if we have not caught and exception
TimeoutExpiredException - Exception in org.activemq
Thrown when an operation cannot be performed in the allowed time, usually a send() message
TimeoutExpiredException() - Constructor for exception org.activemq.TimeoutExpiredException
 
TimeoutExpiredException(String) - Constructor for exception org.activemq.TimeoutExpiredException
 
TIMESTAMP - Static variable in interface org.activemq.transport.stomp.Stomp.Headers.Message
 
TIMESTAMP_INDEX - Static variable in class org.activemq.message.ActiveMQMessage
 
TimeStatisticImpl - Class in org.activemq.management
A time statistic implementation
TimeStatisticImpl(String, String) - Constructor for class org.activemq.management.TimeStatisticImpl
 
TimeStatisticImpl(TimeStatisticImpl, String, String) - Constructor for class org.activemq.management.TimeStatisticImpl
 
TimeStatisticImpl(String, String, String) - Constructor for class org.activemq.management.TimeStatisticImpl
 
toArray() - Method in class org.activemq.service.impl.DefaultQueueList
 
toArray() - Method in class org.activemq.service.impl.QueueListSupport
 
toArray() - Method in interface org.activemq.service.QueueList
Returns an array containing all of the elements in this list in the correct order.
toByteArray() - Method in class org.activemq.util.FastOutputStream
 
toBytes(Packet) - Method in class org.activemq.io.AbstractWireFormat
A helper method which converts a packet into a byte array
toBytes(Packet) - Method in class org.activemq.io.impl.AbstractDefaultWireFormat
 
toBytes(Packet) - Method in class org.activemq.io.impl.DefaultWireFormat
A helper method which converts a packet into a byte array Overrides the WireFormat to make use of the internal BytesOutputStream
toBytes(Packet) - Method in class org.activemq.io.impl.StatelessDefaultWireFormat
A helper method which converts a packet into a byte array Overrides the WireFormat to make use of the internal BytesOutputStream
toBytes(Packet) - Method in interface org.activemq.io.WireFormat
A helper method which converts a packet into a byte array
toBytes() - Method in class org.activemq.message.ActiveMQXid
 
toBytes(Packet) - Method in class org.activemq.transport.stomp.StompWireFormat
A helper method which converts a packet into a byte array
toBytesFromHex(String) - Static method in class org.activemq.message.ActiveMQXid
 
toHexFromBytes(byte[]) - Static method in class org.activemq.message.ActiveMQXid
 
token - Variable in class org.activemq.selector.SelectorParser
 
Token - Class in org.activemq.selector
Describes the input token stream.
Token() - Constructor for class org.activemq.selector.Token
 
token_source - Variable in class org.activemq.selector.SelectorParser
 
tokenImage - Variable in exception org.activemq.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.activemq.selector.SelectorParserConstants
 
TokenMgrError - Error in org.activemq.selector
 
TokenMgrError() - Constructor for error org.activemq.selector.TokenMgrError
 
TokenMgrError(String, int) - Constructor for error org.activemq.selector.TokenMgrError
 
TokenMgrError(boolean, int, int, int, String, char, int) - Constructor for error org.activemq.selector.TokenMgrError
 
toLocalTransactionId() - Method in class org.activemq.message.ActiveMQXid
 
topicConsumerMap - Variable in class org.activemq.transport.NetworkChannel
 
TopicMessageContainer - Interface in org.activemq.service
A Topic based MessageContainer
TopicMessageStore - Interface in org.activemq.store
A MessageStore for durable topic subscriptions
toString() - Method in class org.activemq.ActiveMQMessageConsumer
 
toString() - Method in class org.activemq.ActiveMQQueueSession
 
toString() - Method in class org.activemq.ActiveMQTopicSession
 
toString() - Method in class org.activemq.advisories.TempDestinationAdvisoryEvent
 
toString() - Method in class org.activemq.broker.impl.BrokerClientImpl
 
toString() - Method in class org.activemq.broker.impl.DefaultBroker
 
toString() - Method in class org.activemq.capacity.CapacityMonitorEvent
 
toString() - Method in class org.activemq.filter.BinaryExpression
 
toString() - Method in class org.activemq.filter.ConstantExpression
 
toString(String[]) - Static method in class org.activemq.filter.DestinationPath
Converts the paths to a single String seperated by dots.
toString() - Method in class org.activemq.filter.ExpressionFilter
 
toString() - Method in class org.activemq.filter.MultiExpressionEvaluator.CacheExpression
 
toString() - Method in class org.activemq.filter.PrefixDestinationFilter
 
toString() - Method in class org.activemq.filter.PropertyExpression
 
toString() - Method in class org.activemq.filter.UnaryExpression
 
toString() - Method in class org.activemq.filter.WildcardDestinationFilter
 
toString() - Method in class org.activemq.filter.XPathExpression
 
toString() - Method in class org.activemq.filter.XQueryExpression
 
toString(Packet) - Method in class org.activemq.io.TextWireFormat
Converts the packet into a String
toString() - Method in class org.activemq.io.util.MemoryBoundedQueue
 
toString() - Method in class org.activemq.management.JMSConnectionStatsImpl
 
toString() - Method in class org.activemq.management.JMSConsumerStatsImpl
 
toString() - Method in class org.activemq.management.JMSEndpointStatsImpl
 
toString() - Method in class org.activemq.management.JMSProducerStatsImpl
 
toString() - Method in class org.activemq.management.JMSSessionStatsImpl
 
toString() - Method in class org.activemq.management.StatisticImpl
 
toString() - Method in class org.activemq.message.AbstractPacket
 
toString() - Method in class org.activemq.message.ActiveMQBytesMessage
 
toString() - Method in class org.activemq.message.ActiveMQDestination
 
toString() - Method in class org.activemq.message.ActiveMQMapMessage
 
toString() - Method in class org.activemq.message.ActiveMQMessage
 
toString(int[]) - Method in class org.activemq.message.ActiveMQMessage
 
toString() - Method in class org.activemq.message.ActiveMQObjectMessage
 
toString() - Method in class org.activemq.message.ActiveMQStreamMessage
 
toString() - Method in class org.activemq.message.ActiveMQTextMessage
 
toString() - Method in class org.activemq.message.ActiveMQXid
 
toString() - Method in class org.activemq.message.BrokerAdminCommand
 
toString() - Method in class org.activemq.message.BrokerInfo
 
toString() - Method in class org.activemq.message.CachedValue
 
toString() - Method in class org.activemq.message.CapacityInfo
 
toString() - Method in class org.activemq.message.CapacityInfoRequest
 
toString() - Method in class org.activemq.message.CleanupConnectionInfo
 
toString() - Method in class org.activemq.message.ConnectionInfo
 
toString() - Method in class org.activemq.message.ConsumerInfo
 
toString() - Method in class org.activemq.message.DurableUnsubscribe
 
toString() - Method in class org.activemq.message.IntResponseReceipt
 
toString() - Method in class org.activemq.message.KeepAlive
 
toString() - Method in class org.activemq.message.MessageAck
 
toString() - Method in class org.activemq.message.ProducerInfo
 
toString() - Method in class org.activemq.message.Receipt
 
toString() - Method in class org.activemq.message.ResponseReceipt
 
toString() - Method in class org.activemq.message.SessionInfo
 
toString() - Method in class org.activemq.message.TransactionInfo
 
toString() - Method in class org.activemq.message.WireFormatInfo
 
toString() - Method in class org.activemq.message.XATransactionInfo
 
toString() - Method in class org.activemq.selector.Token
Returns the image.
toString() - Method in class org.activemq.service.boundedvm.DurableMessagePointer
 
toString() - Method in class org.activemq.service.impl.AbstractTransaction
 
toString() - Method in class org.activemq.service.impl.DefaultQueueList
 
toString() - Method in class org.activemq.service.impl.SubscriptionContainerImpl
 
toString() - Method in class org.activemq.service.impl.SubscriptionImpl
 
toString() - Method in class org.activemq.service.MessageIdentity
 
toString() - Method in class org.activemq.service.SubscriberEntry
 
toString() - Method in class org.activemq.transport.activeio.ActiveIOTransportServerChannel
 
toString() - Method in class org.activemq.transport.composite.CompositeTransportChannel
 
toString() - Method in class org.activemq.transport.DiscoveryEvent
 
toString(Destination) - Method in class org.activemq.transport.jabber.JabberWireFormat
 
toString() - Method in class org.activemq.transport.multicast.MulticastDiscoveryAgent
 
toString() - Method in class org.activemq.transport.multicast.MulticastTransportChannel
pretty print for object
toString() - Method in class org.activemq.transport.multicast.MulticastTransportServerChannel
 
toString() - Method in class org.activemq.transport.NetworkChannel
 
toString() - Method in class org.activemq.transport.reliable.ReliableTransportChannel
 
toString() - Method in class org.activemq.transport.tcp.TcpTransportChannel
pretty print for object
toString() - Method in class org.activemq.transport.tcp.TcpTransportServerChannel
 
toString() - Method in class org.activemq.transport.TransportStatusEvent
 
toString() - Method in class org.activemq.transport.udp.UdpTransportChannel
pretty print for object
toString() - Method in class org.activemq.transport.udp.UdpTransportServerChannel
 
toString() - Method in class org.activemq.transport.vm.VmTransportChannel
pretty print for object
toString() - Method in class org.activemq.transport.vm.VmTransportServerChannel
 
Transaction - Interface in org.activemq.service
A Transaction keeps track of all the tasks that must be run before and after transactional events.
TRANSACTION - Static variable in interface org.activemq.transport.stomp.Stomp.Headers
 
TRANSACTION_ID_INDEX - Static variable in class org.activemq.message.ActiveMQMessage
 
TRANSACTION_ID_INDEX - Static variable in class org.activemq.message.MessageAck
 
TRANSACTION_INFO - Static variable in interface org.activemq.message.Packet
Transaction info
TransactionContext - Class in org.activemq.store.jdbc
Helps keep track of the current transaction/JDBC connection.
TransactionContext() - Constructor for class org.activemq.store.jdbc.TransactionContext
 
TransactionContext - Class in org.activemq
A TransactionContext provides the means to control a JMS transaction.
TransactionContext(ActiveMQConnection) - Constructor for class org.activemq.TransactionContext
 
transactionId - Variable in class org.activemq.store.journal.TxCommand
 
transactionIDFromString(String) - Static method in class org.activemq.message.ActiveMQXid
A helper method for the OpenWire protocol to convert a local or XA transaction ID string into an object
transactionIDToString(Object) - Static method in class org.activemq.message.ActiveMQXid
A helper method for the OpenWire protocol to convert a local or XA transaction ID object into a String
TransactionInfo - Class in org.activemq.message
Provides a infomation about a Transaction
TransactionInfo() - Constructor for class org.activemq.message.TransactionInfo
 
transactionInfoReader - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
TransactionInfoReader - Class in org.activemq.io.impl
Reads a TransactionInfo object from a Stream
TransactionInfoReader() - Constructor for class org.activemq.io.impl.TransactionInfoReader
 
transactionInfoWriter - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
TransactionInfoWriter - Class in org.activemq.io.impl
Writes a TransactionInfo object to a Stream
TransactionInfoWriter() - Constructor for class org.activemq.io.impl.TransactionInfoWriter
 
TransactionManager - Class in org.activemq.service
A Transaction keeps track of all the tasks that must be run before and after transactional events.
TransactionManager() - Constructor for class org.activemq.service.TransactionManager
 
TransactionManagerImpl - Class in org.activemq.service.impl
 
TransactionManagerImpl(Broker, TransactionStore) - Constructor for class org.activemq.service.impl.TransactionManagerImpl
 
transactionStore - Variable in class org.activemq.store.journal.JournalMessageStore
 
TransactionStore - Interface in org.activemq.store
Represents the durable store of the commit/rollback operations taken against the broker.
TransactionStore.RecoveryListener - Interface in org.activemq.store
 
TransactionTask - Interface in org.activemq.service
The TransactionTask interface should be implemented by any class whose instances are intended to be executed as part of a transaction event.
transactionTemplate - Variable in class org.activemq.store.journal.JournalMessageStore
 
TransactionTemplate - Class in org.activemq.util
A helper class for running code with a PersistenceAdapter in a transaction.
TransactionTemplate(PersistenceAdapter) - Constructor for class org.activemq.util.TransactionTemplate
 
TransactionType - Interface in org.activemq.message
 
transformDestination(Destination) - Static method in class org.activemq.message.ActiveMQDestination
 
transformDocument(Document) - Method in class org.activemq.spring.ActiveMQBeanDefinitionReader
A hook to transform the source document into a default Spring XML configuration
transformEnvironment(Hashtable) - Method in class org.activemq.jndi.ActiveMQWASInitialContextFactory
Performs following transformation of properties: (java.naming.queue.xxx.yyy,value)=>(queue.xxx/yyy,value) (java.naming.topic.xxx.yyy,value)=>(topic.xxx/yyy,value) (java.naming.connectionFactoryNames,value)=>(connectionFactoryNames,value) (java.naming.provider.url,url1;url2)=>java.naming.provider.url,url1,url1)
TransientQueueBoundedMessageContainer - Class in org.activemq.service.boundedvm
A MessageContainer for transient queues
TransientQueueBoundedMessageContainer(Executor, MemoryBoundedQueueManager, ActiveMQDestination, RedeliveryPolicy, DeadLetterPolicy) - Constructor for class org.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
Construct this beast
TransientQueueBoundedMessageManager - Class in org.activemq.service.boundedvm
A manager of MessageContainer instances
TransientQueueBoundedMessageManager(MemoryBoundedQueueManager, RedeliveryPolicy, DeadLetterPolicy) - Constructor for class org.activemq.service.boundedvm.TransientQueueBoundedMessageManager
Constructor for TransientQueueBoundedMessageManager
TransientQueueBoundedMessageManager.TransientQueueThreadFactory - Class in org.activemq.service.boundedvm
 
TransientQueueBoundedMessageManager.TransientQueueThreadFactory() - Constructor for class org.activemq.service.boundedvm.TransientQueueBoundedMessageManager.TransientQueueThreadFactory
 
TransientQueueSubscription - Class in org.activemq.service.boundedvm
A holder for Transient Queue consumer info and message routing
TransientQueueSubscription(BrokerClient, MemoryBoundedQueue, MemoryBoundedQueue, Filter, ConsumerInfo) - Constructor for class org.activemq.service.boundedvm.TransientQueueSubscription
Construct the TransientQueueSubscription
TransientSubscription - Class in org.activemq.service.boundedvm
A holder for Transient consumer info and message routing
TransientSubscription(Filter, ConsumerInfo, BrokerClient) - Constructor for class org.activemq.service.boundedvm.TransientSubscription
Construct the TransientSubscription
TransientTopicBoundedMessageContainer - Class in org.activemq.service.boundedvm
A MessageContainer for transient topics One of these exists for every active Connection consuming transient Topic messages
TransientTopicBoundedMessageContainer(TransientTopicBoundedMessageManager, BrokerClient, MemoryBoundedQueue) - Constructor for class org.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
Construct this beast
TransientTopicBoundedMessageManager - Class in org.activemq.service.boundedvm
A manager of MessageContainer instances
TransientTopicBoundedMessageManager(MemoryBoundedQueueManager) - Constructor for class org.activemq.service.boundedvm.TransientTopicBoundedMessageManager
Constructor for TransientTopicBoundedMessageManager
TransientTopicMessageContainerManager - Class in org.activemq.service.impl
A default implementation of a Broker of Topic messages for transient consumers
TransientTopicMessageContainerManager(PersistenceAdapter) - Constructor for class org.activemq.service.impl.TransientTopicMessageContainerManager
 
TransientTopicMessageContainerManager(PersistenceAdapter, SubscriptionContainer, FilterFactory, Dispatcher) - Constructor for class org.activemq.service.impl.TransientTopicMessageContainerManager
 
TransientTopicSubscription - Class in org.activemq.service.boundedvm
A holder for Transient Topic consumer info and message routing
TransientTopicSubscription(Filter, ConsumerInfo, BrokerClient) - Constructor for class org.activemq.service.boundedvm.TransientTopicSubscription
Construct the TransientTopicSubscription
TransportChannel - Interface in org.activemq.transport
A TransportChannel is used for tranporting packets between nodes e.g.
TransportChannelFactory - Interface in org.activemq.transport
TransportChannelFactory for creating TransportChannels
TransportChannelFactorySupport - Class in org.activemq.transport
Useful for implementation inheritence
TransportChannelFactorySupport() - Constructor for class org.activemq.transport.TransportChannelFactorySupport
 
TransportChannelListener - Interface in org.activemq.transport
Used by a server to listen for new clients coming and going and reacting accordingly
TransportChannelProvider - Class in org.activemq.transport
A TransportChannel is used for tranporting packets between nodes
TransportChannelProvider() - Constructor for class org.activemq.transport.TransportChannelProvider
 
TransportChannelSupport - Class in org.activemq.transport
Some basic functionality, common across most transport implementations of channels
TransportChannelSupport() - Constructor for class org.activemq.transport.TransportChannelSupport
 
TransportChannelSupport(WireFormat) - Constructor for class org.activemq.transport.TransportChannelSupport
 
transportConnected - Variable in class org.activemq.transport.TransportChannelSupport
 
transportDataIn - Variable in class org.activemq.io.AbstractWireFormat
 
transportDataOut - Variable in class org.activemq.io.AbstractWireFormat
 
TransportServerChannel - Interface in org.activemq.transport
Represents a Server which accepts incoming client connections in the form of TransportChannels which is used inside the JMS Broker
TransportServerChannelFactory - Interface in org.activemq.transport
A TransportServerChannel is used for accepting connections from TransportChannels
TransportServerChannelProvider - Class in org.activemq.transport
locates a protocol specific TransportServerChannelFactory
TransportServerChannelProvider() - Constructor for class org.activemq.transport.TransportServerChannelProvider
 
TransportServerChannelSupport - Class in org.activemq.transport
An abstract base class useful for implementation inheritance
TransportServerChannelSupport(URI) - Constructor for class org.activemq.transport.TransportServerChannelSupport
 
TransportServerChannelSupport(String) - Constructor for class org.activemq.transport.TransportServerChannelSupport
 
TransportStatusEvent - Class in org.activemq.transport
A TransportStatusEvent is raised when the state of the underlying transport channel changes
TransportStatusEvent() - Constructor for class org.activemq.transport.TransportStatusEvent
Default Constructor
TransportStatusEvent(TransportChannel, int) - Constructor for class org.activemq.transport.TransportStatusEvent
Constructs an event with the given channel status.
TransportStatusEventListener - Interface in org.activemq.transport
A listener for TransportStatusEvents
treeBindings - Variable in class org.activemq.jndi.ReadOnlyContext
 
TRUE - Static variable in class org.activemq.filter.ConstantExpression
 
TRUE - Static variable in interface org.activemq.selector.SelectorParserConstants
 
tryCreatePersistenceAdapter(String, File, boolean) - Method in class org.activemq.broker.impl.DefaultBroker
 
TxCommand - Class in org.activemq.store.journal
 
TxCommand(byte, Object, boolean) - Constructor for class org.activemq.store.journal.TxCommand
 
TxCommand() - Constructor for class org.activemq.store.journal.TxCommand
 
txTableName - Variable in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
type - Variable in class org.activemq.store.journal.TxCommand
 
TYPE - Static variable in interface org.activemq.transport.stomp.Stomp.Headers.Message
 
TYPE - Static variable in interface org.activemq.transport.stomp.Stomp.Headers.Send
 
TYPE_INDEX - Static variable in class org.activemq.message.ActiveMQMessage
 

U

UdpTransportChannel - Class in org.activemq.transport.udp
A UDP implementation of a TransportChannel
UdpTransportChannel(WireFormat) - Constructor for class org.activemq.transport.udp.UdpTransportChannel
Construct basic helpers
UdpTransportChannel(WireFormat, URI) - Constructor for class org.activemq.transport.udp.UdpTransportChannel
 
UdpTransportChannel(WireFormat, URI, int) - Constructor for class org.activemq.transport.udp.UdpTransportChannel
 
UdpTransportChannel(WireFormat, DatagramSocket) - Constructor for class org.activemq.transport.udp.UdpTransportChannel
 
UdpTransportChannel(WireFormat, DatagramSocket, int) - Constructor for class org.activemq.transport.udp.UdpTransportChannel
 
UdpTransportChannelFactory - Class in org.activemq.transport.udp
A UDP implementation of a TransportChannelFactory
UdpTransportChannelFactory() - Constructor for class org.activemq.transport.udp.UdpTransportChannelFactory
 
UdpTransportServerChannel - Class in org.activemq.transport.udp
A UDP implementation of TransportServerChannel
UdpTransportServerChannel(URI) - Constructor for class org.activemq.transport.udp.UdpTransportServerChannel
 
UdpTransportServerChannelFactory - Class in org.activemq.transport.udp
A UDP implementation of a TransportServerChannelFactory
UdpTransportServerChannelFactory() - Constructor for class org.activemq.transport.udp.UdpTransportServerChannelFactory
 
unaryExpr() - Method in class org.activemq.selector.SelectorParser
 
UnaryExpression - Class in org.activemq.filter
An expression which performs an operation on two expression values
UnaryExpression(Expression) - Constructor for class org.activemq.filter.UnaryExpression
 
unbind(Name) - Method in class org.activemq.jndi.ReadOnlyContext
 
unbind(String) - Method in class org.activemq.jndi.ReadOnlyContext
 
unconsumedMessagesDispatched - Variable in class org.activemq.service.impl.SubscriptionImpl
 
unregisterBroker(String) - Static method in class org.activemq.ActiveMQConnectionFactory
 
unregisterMessageInterest(MessageIdentity) - Method in class org.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
 
unregisterMessageInterest(MessageIdentity) - Method in class org.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
 
unregisterMessageInterest(MessageIdentity) - Method in class org.activemq.service.impl.DurableQueueMessageContainer
Does nothing since when we receive an acknowledgement on a queue we can delete the message
unregisterMessageInterest(MessageIdentity) - Method in class org.activemq.service.impl.DurableTopicMessageContainer
 
unregisterMessageInterest(MessageIdentity) - Method in interface org.activemq.service.MessageContainer
A message consumer calls this when it's no longer interested in a message so that we know when we can delete (or archive) it
unsubscribe(String) - Method in class org.activemq.ActiveMQQueueSession
 
unsubscribe(String) - Method in class org.activemq.ActiveMQSession
Unsubscribes a durable subscription that has been created by a client.
unsubscribe(String) - Method in class org.activemq.ActiveMQTopicSession
 
unsubscribe(String) - Method in class org.activemq.pool.PooledSession
 
UNSUBSCRIBE - Static variable in interface org.activemq.transport.stomp.Stomp.Commands
 
Unsubscribe - Class in org.activemq.transport.stomp
 
UnsupportedWireFormatException - Exception in org.activemq
This exception is raised if the wire format is not supported by the connected peer
UnsupportedWireFormatException(String) - Constructor for exception org.activemq.UnsupportedWireFormatException
Construct Exception
unwrapLong(Long) - Static method in class org.activemq.service.impl.QueueListSupport
 
updateAcknowledgeStats(BrokerClient, Subscription) - Method in class org.activemq.service.impl.MessageContainerManagerSupport
Updates the message acknowledgement stats
updateBrokerCapacity(int) - Method in interface org.activemq.broker.BrokerClient
Update the peer Connection about the Broker's capacity for messages
updateBrokerCapacity(int) - Method in class org.activemq.broker.impl.BrokerClientImpl
Update the peer Connection about the Broker's capacity for messages
updateHeader(QueueListSupport.Header) - Method in class org.activemq.service.impl.QueueListSupport
Writes the header back to disk after its been changed
updateNextNode(Long, Long) - Method in class org.activemq.service.impl.QueueListSupport
 
updateNode(QueueListSupport.Node) - Method in class org.activemq.service.impl.QueueListSupport
Updates the node
updatePhysicalUri(URI) - Method in class org.activemq.transport.tcp.TcpTransportServerChannel
In cases where we construct ourselves with a zero port we need to regenerate the URI with the real physical port so that people can connect to us via discovery
updatePreviousNode(Long, Long) - Method in class org.activemq.service.impl.QueueListSupport
 
updateSampleTime() - Method in class org.activemq.management.StatisticImpl
 
updateSendStats(BrokerClient, ActiveMQMessage) - Method in class org.activemq.service.impl.MessageContainerManagerSupport
Updates the message sending stats
uri - Variable in class org.activemq.transport.NetworkChannel
 
URIConverter - Class in org.activemq.transport.activeio
 
URIConverter() - Constructor for class org.activemq.transport.activeio.URIConverter
 
URIHelper - Class in org.activemq.util
Some URI based helper methods.
URIHelper(String) - Constructor for class org.activemq.util.URIHelper
Create URIHelper with a path
uris - Variable in class org.activemq.transport.composite.CompositeTransportChannel
 
useAsyncSend - Variable in class org.activemq.ActiveMQConnection
Should we use an async send for persistent non transacted messages ?
useAsyncSend - Variable in class org.activemq.ActiveMQConnectionFactory
Should we use an async send for persistent non transacted messages ?
usedInternally - Variable in class org.activemq.transport.TransportChannelSupport
 
userName - Variable in class org.activemq.ActiveMQConnectionFactory
 
UsernamePasswordCallback - Class in org.activemq.security.jassjacc
A JASS username password CallbackHandler.
UsernamePasswordCallback(String, String) - Constructor for class org.activemq.security.jassjacc.UsernamePasswordCallback
 

V

VALID_ACTIONS - Static variable in class org.activemq.security.jassjacc.JMSBrokerPermission
 
VALID_ACTIONS - Static variable in class org.activemq.security.jassjacc.JMSDestinationPermission
 
validateConnection(int) - Method in interface org.activemq.broker.BrokerClient
Tests the connection to assert that it in fact is alive by asserting that a full round-trip to the client is possible.
validateConnection(int) - Method in class org.activemq.broker.impl.BrokerClientImpl
validate the connection
validateConsumer(ConsumerInfo) - Method in class org.activemq.broker.impl.DefaultBroker
Ensures the consumer is valid, throwing a meaningful exception if not
validateDestination(ActiveMQDestination) - Method in class org.activemq.ActiveMQConnection
 
validateObject(Object) - Method in class org.activemq.pool.SessionPool
 
validateWriteCache() - Method in class org.activemq.io.impl.DefaultWireFormat
 
value - Variable in class org.activemq.service.impl.QueueListSupport.Node
 
variable() - Method in class org.activemq.selector.SelectorParser
 
VMMessageStore - Class in org.activemq.store.vm
An implementation of MessageStore which uses a
VMMessageStore() - Constructor for class org.activemq.store.vm.VMMessageStore
 
VMMessageStore(LinkedHashMap) - Constructor for class org.activemq.store.vm.VMMessageStore
 
VMPersistenceAdapter - Class in org.activemq.store.vm
 
VMPersistenceAdapter() - Constructor for class org.activemq.store.vm.VMPersistenceAdapter
 
VMPersistenceAdapterFactory - Class in org.activemq.store.vm
Factory class that can create PersistenceAdapter objects.
VMPersistenceAdapterFactory() - Constructor for class org.activemq.store.vm.VMPersistenceAdapterFactory
 
VMTopicMessageStore - Class in org.activemq.store.vm
 
VMTopicMessageStore() - Constructor for class org.activemq.store.vm.VMTopicMessageStore
 
VMTopicMessageStore(LinkedHashMap, Map, Map, Map) - Constructor for class org.activemq.store.vm.VMTopicMessageStore
 
VMTransactionManager - Class in org.activemq.store.vm
Keeps track of all the open transactions in the JMS server.
VMTransactionManager(Broker) - Constructor for class org.activemq.store.vm.VMTransactionManager
 
VMTransactionManager(Broker, TransactionStore) - Constructor for class org.activemq.store.vm.VMTransactionManager
 
VMTransactionStore - Class in org.activemq.store.vm
Provides a TransactionStore implementation that can create transaction aware MessageStore objects from non transaction aware MessageStore objects.
VMTransactionStore() - Constructor for class org.activemq.store.vm.VMTransactionStore
 
VMTransactionStore.AddMessageCommand - Interface in org.activemq.store.vm
 
VMTransactionStore.RemoveMessageCommand - Interface in org.activemq.store.vm
 
VMTransactionStore.Tx - Class in org.activemq.store.vm
 
VMTransactionStore.Tx() - Constructor for class org.activemq.store.vm.VMTransactionStore.Tx
 
VmTransportChannel - Class in org.activemq.transport.vm
A VM implementation of a TransportChannel
VmTransportChannel() - Constructor for class org.activemq.transport.vm.VmTransportChannel
 
VmTransportChannel(Channel, Channel) - Constructor for class org.activemq.transport.vm.VmTransportChannel
 
VmTransportChannel(int) - Constructor for class org.activemq.transport.vm.VmTransportChannel
 
VmTransportChannelFactory - Class in org.activemq.transport.vm
A VM implementation of a TransportChannelFactory
VmTransportChannelFactory() - Constructor for class org.activemq.transport.vm.VmTransportChannelFactory
 
VmTransportServerChannel - Class in org.activemq.transport.vm
A VM implementation of TransportServerChannel
VmTransportServerChannel(URI) - Constructor for class org.activemq.transport.vm.VmTransportServerChannel
 
VmTransportServerChannelFactory - Class in org.activemq.transport.vm
A VM implementation of a TransportServerChannelFactory
VmTransportServerChannelFactory() - Constructor for class org.activemq.transport.vm.VmTransportServerChannelFactory
 

W

WAIT_TIMEOUT - Static variable in class org.activemq.io.util.MemoryBoundedQueue
 
waitForActiveConnections(int, long) - Method in class org.activemq.advisories.ConnectionAdvisor
Waits until the number of active connections is equivalent to the number supplied, or the timeout is exceeded
waitForMessagesToArrive(int) - Method in class org.activemq.spring.TestingConsumer
 
waitForMessageToArrive() - Method in class org.activemq.spring.TestingConsumer
 
wakeup(Subscription) - Method in interface org.activemq.service.Dispatcher
Called to indicate that there is work to do on a Subscription this will wake up a Dispatch Worker if it is waiting for messages to dispatch
wakeup() - Method in interface org.activemq.service.Dispatcher
Called to indicate that there is work to do this will wake up a Dispatch Worker if it is waiting for messages to dispatch
wakeup(Subscription) - Method in class org.activemq.service.impl.DispatcherImpl
Called to indicate that there is work to do on a Subscription this will wake up a Dispatch Worker if it is waiting for messages to dispatch
wakeup() - Method in class org.activemq.service.impl.DispatcherImpl
Called to indicate that there is work to do this will wake up a Dispatch Worker if it is waiting for messages to dispatch
wakeup() - Method in class org.activemq.service.impl.DispatchWorker
Called to indicate that there is work to do on a Subscription this will wake up a Dispatch Worker if it is waiting for messages to dispatch
wasPrepared - Variable in class org.activemq.store.journal.TxCommand
 
WildcardDestinationFilter - Class in org.activemq.filter
Matches messages which contain wildcards like "A.B.*.*"
WildcardDestinationFilter(String[]) - Constructor for class org.activemq.filter.WildcardDestinationFilter
An array of paths containing * characters
WIRE_FORMAT_INFO - Static variable in interface org.activemq.message.Packet
Infomation about the wire format expected
WIRE_FORMAT_VERSION - Static variable in class org.activemq.io.impl.AbstractDefaultWireFormat
Current wire format version for this implementation
WireByteArrayInputStream - Class in org.activemq.io.util
Optimized ByteArrayInputStream that can be used more than once.
WireByteArrayInputStream(byte[]) - Constructor for class org.activemq.io.util.WireByteArrayInputStream
Creates a WireByteArrayInputStream.
WireByteArrayInputStream(byte[], int, int) - Constructor for class org.activemq.io.util.WireByteArrayInputStream
Creates WireByteArrayInputStream that uses buf as its buffer array.
WireByteArrayInputStream(ByteArray) - Constructor for class org.activemq.io.util.WireByteArrayInputStream
Create a WireByteArrayInputStream that uses a ByteArray
WireByteArrayInputStream() - Constructor for class org.activemq.io.util.WireByteArrayInputStream
Creates WireByteArrayInputStream with a minmalist byte array
WireByteArrayOutputStream - Class in org.activemq.io.util
Optimized ByteArrayOutputStream
WireByteArrayOutputStream() - Constructor for class org.activemq.io.util.WireByteArrayOutputStream
Creates a new byte array output stream.
WireByteArrayOutputStream(int) - Constructor for class org.activemq.io.util.WireByteArrayOutputStream
Creates a new byte array output stream, with a buffer capacity of the specified size, in bytes.
WireFormat - Interface in org.activemq.io
Represents a strategy of encoding packets on the wire or on disk using some kind of serialization or wire format.
wireFormat - Variable in class org.activemq.store.jdbc.JDBCMessageStore
 
wireFormat - Variable in class org.activemq.transport.peer.PeerTransportChannel
 
WireFormatInfo - Class in org.activemq.message
Describes a Connection
WireFormatInfo() - Constructor for class org.activemq.message.WireFormatInfo
 
wireFormatInfoReader - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
WireFormatInfoReader - Class in org.activemq.io.impl
Reads a ConnnectionInfo object from a Stream
wireFormatInfoWriter - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
WireFormatInfoWriter - Class in org.activemq.io.impl
Writes a ConsumerInfo object to a Stream
WireFormatInfoWriter() - Constructor for class org.activemq.io.impl.WireFormatInfoWriter
 
WireFormatLoader - Class in org.activemq.io
Represents a strategy of encoding packets on the wire or on disk using some kind of serialization or wire format.
WireFormatLoader() - Constructor for class org.activemq.io.WireFormatLoader
Default Constructor
WireFormatLoader(WireFormat) - Constructor for class org.activemq.io.WireFormatLoader
Construct WireFormatLoader with the prefered WireFormat
wireFormatVersion - Variable in class org.activemq.io.impl.AbstractPacketMarshaller
 
wireFormatVersion - Variable in class org.activemq.io.impl.AbstractPacketReader
 
wireFormatVersion - Variable in class org.activemq.io.impl.AbstractPacketWriter
 
WireGZIPOutputStream - Class in org.activemq.io.util
Compression stream
WireGZIPOutputStream(OutputStream) - Constructor for class org.activemq.io.util.WireGZIPOutputStream
Compression stream
wrapLong(long) - Static method in class org.activemq.service.impl.QueueListSupport
 
write(int) - Method in class org.activemq.io.util.WireByteArrayOutputStream
Writes the specified byte to this byte array output stream.
write(byte[], int, int) - Method in class org.activemq.io.util.WireByteArrayOutputStream
Writes len bytes from the specified byte array starting at offset off to this byte array output stream.
write(DataOutput) - Method in class org.activemq.message.ActiveMQXid
Writes the Xid to a stream
write(int) - Method in class org.activemq.streams.JMSOutputStream
write a byte on to the stream
write(byte[], int, int) - Method in class org.activemq.streams.JMSOutputStream
write a byte array to the stream
write(int) - Method in class org.activemq.transport.tcp.TcpBufferedOutputStream
write a byte on to the stream
write(byte[], int, int) - Method in class org.activemq.transport.tcp.TcpBufferedOutputStream
write a byte array to the stream
writeBody(DataOutput) - Method in class org.activemq.message.ActiveMQMapMessage
 
writeBody(DataOutput) - Method in class org.activemq.message.ActiveMQMessage
Used serialize the message body to an output stream
writeBody(DataOutput) - Method in class org.activemq.message.ActiveMQObjectMessage
Used serialize the message body to an output stream
writeBody(DataOutput) - Method in class org.activemq.message.ActiveMQTextMessage
Used serialize the message body to an output stream
writeBody(DataOutput) - Method in interface org.activemq.message.BodyPacket
 
writeBody(DataOutput) - Method in class org.activemq.message.CachedValue
 
writeBody(DataOutput) - Method in class org.activemq.message.MessageAck
 
writeBoolean(boolean) - Method in class org.activemq.message.ActiveMQBytesMessage
Writes a boolean to the bytes message stream as a 1-byte value.
writeBoolean(boolean) - Method in class org.activemq.message.ActiveMQStreamMessage
Writes a boolean to the stream message.
writeByte(byte) - Method in class org.activemq.message.ActiveMQBytesMessage
Writes a byte to the bytes message stream as a 1-byte value.
writeByte(byte) - Method in class org.activemq.message.ActiveMQStreamMessage
Writes a byte to the stream message.
writeBytes(byte[]) - Method in class org.activemq.message.ActiveMQBytesMessage
Writes a byte array to the bytes message stream.
writeBytes(byte[], int, int) - Method in class org.activemq.message.ActiveMQBytesMessage
Writes a portion of a byte array to the bytes message stream.
writeBytes(byte[]) - Method in class org.activemq.message.ActiveMQStreamMessage
Writes a byte array field to the stream message.
writeBytes(byte[], int, int) - Method in class org.activemq.message.ActiveMQStreamMessage
Writes a portion of a byte array as a byte array field to the stream message.
writeBytes(DataOutput, byte[]) - Method in class org.activemq.message.ActiveMQXid
 
writeBytesMessage(ActiveMQBytesMessage, DataOutput) - Method in class org.activemq.transport.jabber.JabberWireFormat
 
writeChar(char) - Method in class org.activemq.message.ActiveMQBytesMessage
Writes a char to the bytes message stream as a 2-byte value, high byte first.
writeChar(char) - Method in class org.activemq.message.ActiveMQStreamMessage
Writes a char to the stream message.
writeCommand(String, boolean) - Method in class org.activemq.store.journal.JournalPersistenceAdapter
 
writeDestination(ActiveMQDestination, DataOutput) - Method in class org.activemq.io.impl.AbstractPacketMarshaller
Writes the given destination to the stream
writeDouble(double) - Method in class org.activemq.message.ActiveMQBytesMessage
Converts the double argument to a long using the doubleToLongBits method in class Double, and then writes that long value to the bytes message stream as an 8-byte quantity, high byte first.
writeDouble(double) - Method in class org.activemq.message.ActiveMQStreamMessage
Writes a double to the stream message.
writeEndElement(XMLStreamReader) - Method in class org.activemq.transport.jabber.JabberWireFormat
 
writeExternal(ObjectOutput) - Method in class org.activemq.advisories.TempDestinationAdvisoryEvent
write to a stream
writeExternal(ObjectOutput) - Method in class org.activemq.message.ActiveMQXid
 
writeExternal(ObjectOutput) - Method in class org.activemq.message.PacketFacade
 
writeExternal(ObjectOutput) - Method in class org.activemq.service.impl.MessageEntry
 
writeExternal(ObjectOutput) - Method in class org.activemq.service.SubscriberEntry
 
writeFloat(float) - Method in class org.activemq.message.ActiveMQBytesMessage
Converts the float argument to an int using the floatToIntBits method in class Float, and then writes that int value to the bytes message stream as a 4-byte quantity, high byte first.
writeFloat(float) - Method in class org.activemq.message.ActiveMQStreamMessage
Writes a float to the stream message.
writeInt(int) - Method in class org.activemq.message.ActiveMQBytesMessage
Writes an int to the bytes message stream as four bytes, high byte first.
writeInt(int) - Method in class org.activemq.message.ActiveMQStreamMessage
Writes an int to the stream message.
writeLong(long) - Method in class org.activemq.message.ActiveMQBytesMessage
Writes a long to the bytes message stream as eight bytes, high byte first.
writeLong(long) - Method in class org.activemq.message.ActiveMQStreamMessage
Writes a long to the stream message.
writeMapProperties(Map, DataOutput) - Method in class org.activemq.message.ActiveMQMessage
write map properties to an output stream
writeMessage(ActiveMQMessage, String, DataOutput) - Method in class org.activemq.transport.jabber.JabberWireFormat
 
writeMutex - Variable in class org.activemq.io.impl.DefaultWireFormat
 
writeNullableUTF(ObjectOutput, String) - Static method in class org.activemq.service.SubscriberEntry
 
writeObject(Object, DataOutput) - Method in class org.activemq.io.impl.AbstractPacketMarshaller
Simple (but inefficent) utility method to write an object on to a stream
writeObject(Object, DataOutput) - Method in class org.activemq.io.impl.AbstractPacketWriter
Simple (but inefficent) utility method to write an object on to a stream
writeObject(Object) - Method in class org.activemq.message.ActiveMQBytesMessage
Writes an object to the bytes message stream.
writeObject(Object) - Method in class org.activemq.message.ActiveMQStreamMessage
Writes an object to the stream message.
writeObject(Object) - Static method in class org.activemq.util.SerializationHelper
Serialize an Object to a ByteArray
writeObject(OutputStream, Object) - Static method in class org.activemq.util.SerializationHelper
Write an Object to an OutputStream
writeObjectMessage(ActiveMQObjectMessage, DataOutput) - Method in class org.activemq.transport.jabber.JabberWireFormat
 
writePacket(String, Packet) - Method in class org.activemq.io.AbstractWireFormat
Writes the given package to a new datagram
writePacket(Packet, DataOutput) - Method in class org.activemq.io.impl.AbstractDefaultWireFormat
 
writePacket(Packet, DataOutput) - Method in class org.activemq.io.impl.AbstractPacketMarshaller
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.activemq.io.impl.AbstractPacketWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.activemq.io.impl.ActiveMQMessageWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.activemq.io.impl.BrokerAdminCommandWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.activemq.io.impl.BrokerInfoWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.activemq.io.impl.CachedValueWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.activemq.io.impl.CapacityInfoRequestWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.activemq.io.impl.CapacityInfoWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.activemq.io.impl.CleanupConnectionInfoWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.activemq.io.impl.ConnectionInfoWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.activemq.io.impl.ConsumerInfoWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.activemq.io.impl.DefaultWireFormat
 
writePacket(Packet, DataOutput) - Method in class org.activemq.io.impl.DurableUnsubscribeWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.activemq.io.impl.IntResponseReceiptWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.activemq.io.impl.KeepAliveWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.activemq.io.impl.MessageAckWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in interface org.activemq.io.impl.PacketWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.activemq.io.impl.ProducerInfoWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.activemq.io.impl.ReceiptWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.activemq.io.impl.ResponseReceiptWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.activemq.io.impl.SessionInfoWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.activemq.io.impl.StatelessDefaultWireFormat
 
writePacket(Packet, PacketByteArrayOutputStream) - Method in class org.activemq.io.impl.StatelessDefaultWireFormat
Write a Packet to a PacketByteArrayOutputStream
writePacket(Packet, DataOutput) - Method in class org.activemq.io.impl.TransactionInfoWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.activemq.io.impl.WireFormatInfoWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.activemq.io.impl.XATransactionInfoWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in interface org.activemq.io.WireFormat
Writes the packet to the given output stream
writePacket(String, Packet) - Method in interface org.activemq.io.WireFormat
Writes the given package to a new datagram
writePacket(String, Packet, boolean) - Method in class org.activemq.store.journal.JournalPersistenceAdapter
 
writePacket(String, String, MessageIdentity, boolean) - Method in class org.activemq.store.journal.JournalPersistenceAdapter
 
writePacket(Packet, DataOutput) - Method in class org.activemq.transport.jabber.JabberWireFormat
 
writePacket(Packet, DataOutput) - Method in class org.activemq.transport.stomp.StompWireFormat
 
writePacket(String, Packet) - Method in class org.activemq.transport.stomp.StompWireFormat
Writes the given package to a new datagram
writePacketToByteArray(Packet) - Method in class org.activemq.io.impl.AbstractPacketMarshaller
Serializes a Packet int a byte array
writePacketToByteArray(Packet) - Method in class org.activemq.io.impl.AbstractPacketWriter
Serializes a Packet int a byte array
writePacketToByteArray(Packet) - Method in interface org.activemq.io.impl.PacketWriter
Serializes a Packet int a byte array
writeQName(QName) - Method in class org.activemq.transport.jabber.JabberWireFormat
 
writeShort(short) - Method in class org.activemq.message.ActiveMQBytesMessage
Writes a short to the bytes message stream as two bytes, high byte first.
writeShort(short) - Method in class org.activemq.message.ActiveMQStreamMessage
Writes a short to the stream message.
writeStartElement(XMLStreamReader) - Method in class org.activemq.transport.jabber.JabberWireFormat
 
writeString(String) - Method in class org.activemq.message.ActiveMQStreamMessage
Writes a String to the stream message.
writeText(DataOutput) - Method in class org.activemq.message.ActiveMQTextMessage
dumps the text body as UTF-8
writeTextMessage(ActiveMQTextMessage, DataOutput) - Method in class org.activemq.transport.jabber.JabberWireFormat
 
writeToStream(ActiveMQDestination, DataOutput) - Static method in class org.activemq.message.ActiveMQDestination
Write an ActiveMQDestination to a Stream
writeToStream(DataOutput) - Method in class org.activemq.util.BitArray
write the bits to an output stream
writeTxCommand(TxCommand, boolean) - Method in class org.activemq.store.journal.JournalPersistenceAdapter
 
writeUTF(String, DataOutput) - Method in class org.activemq.io.impl.AbstractPacketMarshaller
simple helper method to ensure null strings are catered for
writeUTF(String, DataOutput) - Method in class org.activemq.io.impl.AbstractPacketWriter
simple helper method to ensure null strings are catered for
writeUTF(String) - Method in class org.activemq.message.ActiveMQBytesMessage
Writes a string to the bytes message stream using UTF-8 encoding in a machine-independent manner.

X

XA_COMMIT - Static variable in class org.activemq.store.journal.TxCommand
 
XA_PREPARE - Static variable in class org.activemq.store.journal.TxCommand
 
XA_RECOVER - Static variable in interface org.activemq.message.TransactionType
Get a list of all the XIDs that are currently prepared.
XA_ROLLBACK - Static variable in class org.activemq.store.journal.TxCommand
 
XA_TRANS_INDEX - Static variable in class org.activemq.message.ActiveMQMessage
 
XA_TRANS_INDEX - Static variable in class org.activemq.message.MessageAck
 
XA_TRANSACTION_INFO - Static variable in interface org.activemq.message.Packet
XA Transaction info
XalanXPathEvaluator - Class in org.activemq.filter
 
XalanXPathEvaluator(String) - Constructor for class org.activemq.filter.XalanXPathEvaluator
 
XATransactionCommand - Class in org.activemq.service.impl
 
XATransactionCommand(ActiveMQXid, Map, TransactionStore) - Constructor for class org.activemq.service.impl.XATransactionCommand
 
XATransactionInfo - Class in org.activemq.message
Provides a infomation about an XA Transaction
XATransactionInfo() - Constructor for class org.activemq.message.XATransactionInfo
 
xaTransactionInfoReader - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
XATransactionInfoReader - Class in org.activemq.io.impl
Reads a TransactionInfo object from a Stream
XATransactionInfoReader() - Constructor for class org.activemq.io.impl.XATransactionInfoReader
 
xaTransactionInfoWriter - Variable in class org.activemq.io.impl.AbstractDefaultWireFormat
 
XATransactionInfoWriter - Class in org.activemq.io.impl
Writes a TransactionInfo object to a Stream
XATransactionInfoWriter() - Constructor for class org.activemq.io.impl.XATransactionInfoWriter
 
xidDataType - Variable in class org.activemq.store.jdbc.adapter.DefaultStatementProvider
 
XMLBeansXPathEvaluator - Class in org.activemq.filter
 
XMLBeansXPathEvaluator(String) - Constructor for class org.activemq.filter.XMLBeansXPathEvaluator
 
XmlConfigHelper - Class in org.activemq
Helper methods to avoid a runtime dependency on Spring unless its used to configure the ActiveMQ broker via the XML configuration
XmlConfigHelper() - Constructor for class org.activemq.XmlConfigHelper
 
XPATH - Static variable in interface org.activemq.selector.SelectorParserConstants
 
XPathExpression - Class in org.activemq.filter
Used to evaluate an XPath Expression in a JMS selector.
XPathExpression.XPathEvaluator - Interface in org.activemq.filter
 
XQUERY - Static variable in interface org.activemq.selector.SelectorParserConstants
 
XQueryExpression - Class in org.activemq.filter
Used to evaluate an XQuery Expression in a JMS selector.

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

Copyright © 2004-2010 Protique, Ltd.. All Rights Reserved.