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

A

ACTIVEMQ_BROKER_INFO - Static variable in interface org.codehaus.activemq.message.Packet
Broker infomation message
ACTIVEMQ_BYTES_MESSAGE - Static variable in interface org.codehaus.activemq.message.Packet
ActiveMQBytesMessage
ACTIVEMQ_CONNECTION_INFO - Static variable in interface org.codehaus.activemq.message.Packet
Connection info message
ACTIVEMQ_MAP_MESSAGE - Static variable in interface org.codehaus.activemq.message.Packet
ActiveMQMapMessage object
ACTIVEMQ_MESSAGE - Static variable in interface org.codehaus.activemq.message.Packet
ActiveMQMessage object
ACTIVEMQ_MSG_ACK - Static variable in interface org.codehaus.activemq.message.Packet
Message acknowledge
ACTIVEMQ_OBJECT_MESSAGE - Static variable in interface org.codehaus.activemq.message.Packet
ActiveMQObjectMessage object
ACTIVEMQ_QUEUE - Static variable in class org.codehaus.activemq.message.ActiveMQDestination
Queue Destination object
ACTIVEMQ_STREAM_MESSAGE - Static variable in interface org.codehaus.activemq.message.Packet
ActiveMQStreamMessage object
ACTIVEMQ_TEMPORARY_QUEUE - Static variable in class org.codehaus.activemq.message.ActiveMQDestination
Temporary Queue Destination object
ACTIVEMQ_TEMPORARY_TOPIC - Static variable in class org.codehaus.activemq.message.ActiveMQDestination
Temporary Topic Destination object
ACTIVEMQ_TEXT_MESSAGE - Static variable in interface org.codehaus.activemq.message.Packet
ActiveMQTextMessage object
ACTIVEMQ_TOPIC - Static variable in class org.codehaus.activemq.message.ActiveMQDestination
Topic Destination object
AND - Static variable in interface org.codehaus.activemq.selector.SelectorParserConstants
 
ANY_CHILD - Static variable in class org.codehaus.activemq.filter.DestinationFilter
 
ANY_CHILD - Static variable in class org.codehaus.activemq.filter.DestinationMap
 
ANY_CHILD - Static variable in class org.codehaus.activemq.filter.DestinationMapNode
 
ANY_DESCENDENT - Static variable in class org.codehaus.activemq.filter.DestinationFilter
 
ANY_DESCENDENT - Static variable in class org.codehaus.activemq.filter.DestinationMap
 
ANY_DESCENDENT - Static variable in class org.codehaus.activemq.filter.DestinationMapNode
 
AbstractPacket - class org.codehaus.activemq.message.AbstractPacket.
Abstract class for a transportable Packet
AbstractPacket() - Constructor for class org.codehaus.activemq.message.AbstractPacket
 
AbstractPacketReader - class org.codehaus.activemq.message.AbstractPacketReader.
Allows instances implementing Packet interface to be deserailized
AbstractPacketReader() - Constructor for class org.codehaus.activemq.message.AbstractPacketReader
 
AbstractPacketWriter - class org.codehaus.activemq.message.AbstractPacketWriter.
Allows instances implementing Packet interface to be serailized/deserailized
AbstractPacketWriter() - Constructor for class org.codehaus.activemq.message.AbstractPacketWriter
 
AbstractTransaction - class org.codehaus.activemq.service.impl.AbstractTransaction.
Keeps track of all the actions the need to be done when a transaction does a commit or rollback.
AbstractTransaction(Broker) - Constructor for class org.codehaus.activemq.service.impl.AbstractTransaction
 
ActiveMQActivationSpec - class org.codehaus.activemq.ra.ActiveMQActivationSpec.
 
ActiveMQActivationSpec() - Constructor for class org.codehaus.activemq.ra.ActiveMQActivationSpec
 
ActiveMQAsfEndpointWorker - class org.codehaus.activemq.ra.ActiveMQAsfEndpointWorker.
 
ActiveMQAsfEndpointWorker(ActiveMQResourceAdapter, ActiveMQEndpointActivationKey) - Constructor for class org.codehaus.activemq.ra.ActiveMQAsfEndpointWorker
 
ActiveMQAsfEndpointWorker.ServerSessionImpl - class org.codehaus.activemq.ra.ActiveMQAsfEndpointWorker.ServerSessionImpl.
 
ActiveMQAsfEndpointWorker.ServerSessionImpl(ActiveMQAsfEndpointWorker.ServerSessionPoolImpl, Session) - Constructor for class org.codehaus.activemq.ra.ActiveMQAsfEndpointWorker.ServerSessionImpl
 
ActiveMQAsfEndpointWorker.ServerSessionPoolImpl - class org.codehaus.activemq.ra.ActiveMQAsfEndpointWorker.ServerSessionPoolImpl.
 
ActiveMQAsfEndpointWorker.ServerSessionPoolImpl() - Constructor for class org.codehaus.activemq.ra.ActiveMQAsfEndpointWorker.ServerSessionPoolImpl
 
ActiveMQBaseEndpointWorker - class org.codehaus.activemq.ra.ActiveMQBaseEndpointWorker.
 
ActiveMQBaseEndpointWorker(ActiveMQResourceAdapter, ActiveMQEndpointActivationKey) - Constructor for class org.codehaus.activemq.ra.ActiveMQBaseEndpointWorker
 
ActiveMQBeanDefinitionReader - class org.codehaus.activemq.spring.ActiveMQBeanDefinitionReader.
 
ActiveMQBeanDefinitionReader(BeanDefinitionRegistry, String) - Constructor for class org.codehaus.activemq.spring.ActiveMQBeanDefinitionReader
 
ActiveMQBeanFactory - class org.codehaus.activemq.spring.ActiveMQBeanFactory.
A Spring BeanFactory for creating ActiveMQ objects
ActiveMQBeanFactory(String, Resource) - Constructor for class org.codehaus.activemq.spring.ActiveMQBeanFactory
Create a new ActiveMQBeanFactory with the given resource, which must be parsable using DOM.
ActiveMQBeanFactory(String, InputStream) - Constructor for class org.codehaus.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.codehaus.activemq.spring.ActiveMQBeanFactory
Create a new ActiveMQBeanFactory with the given input stream, which must be parsable using DOM.
ActiveMQBytesMessage - class org.codehaus.activemq.message.ActiveMQBytesMessage.
A BytesMessage object is used to send a message containing a stream of uninterpreted bytes.
ActiveMQBytesMessage() - Constructor for class org.codehaus.activemq.message.ActiveMQBytesMessage
 
ActiveMQBytesMessageReader - class org.codehaus.activemq.message.ActiveMQBytesMessageReader.
Reads a Message object to a Stream
ActiveMQBytesMessageReader() - Constructor for class org.codehaus.activemq.message.ActiveMQBytesMessageReader
 
ActiveMQBytesMessageWriter - class org.codehaus.activemq.message.ActiveMQBytesMessageWriter.
Writes a Message object to a Stream
ActiveMQBytesMessageWriter() - Constructor for class org.codehaus.activemq.message.ActiveMQBytesMessageWriter
 
ActiveMQConnection - class org.codehaus.activemq.ActiveMQConnection.
A Connection object is a client's active connection to its JMS provider.
ActiveMQConnection(ActiveMQConnectionFactory, String, String, TransportChannel) - Constructor for class org.codehaus.activemq.ActiveMQConnection
Constructs a connection from an existing TransportChannel and user/password.
ActiveMQConnection(ActiveMQConnectionFactory, String, String) - Constructor for class org.codehaus.activemq.ActiveMQConnection
 
ActiveMQConnectionConsumer - class org.codehaus.activemq.ActiveMQConnectionConsumer.
For application servers, Connection objects provide a special facility for creating a ConnectionConsumer (optional).
ActiveMQConnectionConsumer(ActiveMQConnection, ServerSessionPool, ConsumerInfo, int) - Constructor for class org.codehaus.activemq.ActiveMQConnectionConsumer
Create a ConnectionConsumer
ActiveMQConnectionFactory - class org.codehaus.activemq.ActiveMQConnectionFactory.
A ConnectionFactory is an an Administed object, and is used for creating Connections.
ActiveMQConnectionFactory() - Constructor for class org.codehaus.activemq.ActiveMQConnectionFactory
Default Constructor for ActiveMQConnectionFactory
ActiveMQConnectionFactory(String) - Constructor for class org.codehaus.activemq.ActiveMQConnectionFactory
 
ActiveMQConnectionFactory(String, String, String) - Constructor for class org.codehaus.activemq.ActiveMQConnectionFactory
 
ActiveMQConnectionFactory(BrokerContainer) - Constructor for class org.codehaus.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.codehaus.activemq.ActiveMQConnectionFactory
Constructs a ConnectionFactory with an already configured and started BrokerContainer ready for use in embedded mode and the brokerURL connection.
ActiveMQConnectionFactory - class org.codehaus.activemq.ra.ActiveMQConnectionFactory.
 
ActiveMQConnectionFactory(ActiveMQManagedConnectionFactory, ConnectionManager, ActiveMQConnectionRequestInfo) - Constructor for class org.codehaus.activemq.ra.ActiveMQConnectionFactory
 
ActiveMQConnectionMetaData - class org.codehaus.activemq.ActiveMQConnectionMetaData.
A ConnectionMetaData object provides information describing the Connection object.
ActiveMQConnectionMetaData() - Constructor for class org.codehaus.activemq.ActiveMQConnectionMetaData
 
ActiveMQConnectionRequestInfo - class org.codehaus.activemq.ra.ActiveMQConnectionRequestInfo.
 
ActiveMQConnectionRequestInfo() - Constructor for class org.codehaus.activemq.ra.ActiveMQConnectionRequestInfo
 
ActiveMQConnectorGBean - class org.codehaus.activemq.gbean.ActiveMQConnectorGBean.
Default implementation of the ActiveMQ connector
ActiveMQConnectorGBean(ActiveMQContainer) - Constructor for class org.codehaus.activemq.gbean.ActiveMQConnectorGBean
 
ActiveMQContainer - interface org.codehaus.activemq.gbean.ActiveMQContainer.
An interface to the ActiveMQContainerGBean for use by the ActiveMQConnectorGBean.
ActiveMQContainerGBean - class org.codehaus.activemq.gbean.ActiveMQContainerGBean.
Default implementation of the ActiveMQ Message Server
ActiveMQContainerGBean() - Constructor for class org.codehaus.activemq.gbean.ActiveMQContainerGBean
 
ActiveMQContainerGBean(ServerInfo, String, String) - Constructor for class org.codehaus.activemq.gbean.ActiveMQContainerGBean
 
ActiveMQDestination - class org.codehaus.activemq.message.ActiveMQDestination.
A Destination object encapsulates a provider-specific address.
ActiveMQDestination() - Constructor for class org.codehaus.activemq.message.ActiveMQDestination
The Default Constructor
ActiveMQDestination(String) - Constructor for class org.codehaus.activemq.message.ActiveMQDestination
Construct the ActiveMQDestination with a defined physical name;
ActiveMQDtdResolver - class org.codehaus.activemq.spring.ActiveMQDtdResolver.
EntityResolver implementation for the ActiveMQ DTD, to load the DTD from the ActiveMQ classpath JAR file.
ActiveMQDtdResolver() - Constructor for class org.codehaus.activemq.spring.ActiveMQDtdResolver
 
ActiveMQEndpointActivationKey - class org.codehaus.activemq.ra.ActiveMQEndpointActivationKey.
 
ActiveMQEndpointActivationKey(MessageEndpointFactory, ActiveMQActivationSpec) - Constructor for class org.codehaus.activemq.ra.ActiveMQEndpointActivationKey
 
ActiveMQInitialContextFactory - class org.codehaus.activemq.jndi.ActiveMQInitialContextFactory.
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.codehaus.activemq.jndi.ActiveMQInitialContextFactory
 
ActiveMQManagedConnection - class org.codehaus.activemq.ra.ActiveMQManagedConnection.
ActiveMQManagedConnection maps to real physical connection to the server.
ActiveMQManagedConnection(Subject, ActiveMQResourceAdapter, ActiveMQConnectionRequestInfo) - Constructor for class org.codehaus.activemq.ra.ActiveMQManagedConnection
 
ActiveMQManagedConnectionFactory - class org.codehaus.activemq.ra.ActiveMQManagedConnectionFactory.
 
ActiveMQManagedConnectionFactory() - Constructor for class org.codehaus.activemq.ra.ActiveMQManagedConnectionFactory
 
ActiveMQMapMessage - class org.codehaus.activemq.message.ActiveMQMapMessage.
A MapMessage object is used to send a set of name-value pairs.
ActiveMQMapMessage() - Constructor for class org.codehaus.activemq.message.ActiveMQMapMessage
 
ActiveMQMapMessageReader - class org.codehaus.activemq.message.ActiveMQMapMessageReader.
Reads a Message object to a Stream
ActiveMQMapMessageReader() - Constructor for class org.codehaus.activemq.message.ActiveMQMapMessageReader
 
ActiveMQMapMessageWriter - class org.codehaus.activemq.message.ActiveMQMapMessageWriter.
Writes a Message object to a Stream
ActiveMQMapMessageWriter() - Constructor for class org.codehaus.activemq.message.ActiveMQMapMessageWriter
 
ActiveMQMessage - class org.codehaus.activemq.message.ActiveMQMessage.
The Message interface is the root interface of all JMS messages.
ActiveMQMessage() - Constructor for class org.codehaus.activemq.message.ActiveMQMessage
 
ActiveMQMessageAudit - class org.codehaus.activemq.ActiveMQMessageAudit.
Provides basic audit functions for Messages
ActiveMQMessageAudit() - Constructor for class org.codehaus.activemq.ActiveMQMessageAudit
Default Constructor windowSize = 1024, maximumNumberOfProducersToTrack = 128
ActiveMQMessageAudit(int, int) - Constructor for class org.codehaus.activemq.ActiveMQMessageAudit
Construct a MessageAudit
ActiveMQMessageConsumer - class org.codehaus.activemq.ActiveMQMessageConsumer.
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.codehaus.activemq.ActiveMQMessageConsumer
Create a MessageConsumer
ActiveMQMessageDispatcher - interface org.codehaus.activemq.ActiveMQMessageDispatcher.
An internal dispatcher for ActiveMQMessage types
ActiveMQMessageProducer - class org.codehaus.activemq.ActiveMQMessageProducer.
A client uses a MessageProducer object to send messages to a destination.
ActiveMQMessageProducer(ActiveMQSession, ActiveMQDestination) - Constructor for class org.codehaus.activemq.ActiveMQMessageProducer
 
ActiveMQMessageReader - class org.codehaus.activemq.message.ActiveMQMessageReader.
Writes a ProducerInfo object to a Stream
ActiveMQMessageReader() - Constructor for class org.codehaus.activemq.message.ActiveMQMessageReader
 
ActiveMQMessageTransformation - class org.codehaus.activemq.ActiveMQMessageTransformation.
Transforms foreign Destinations and Messages to ActiveMQ formats
ActiveMQMessageTransformation() - Constructor for class org.codehaus.activemq.ActiveMQMessageTransformation
 
ActiveMQMessageWriter - class org.codehaus.activemq.message.ActiveMQMessageWriter.
Writes a ProducerInfo object to a Stream
ActiveMQMessageWriter() - Constructor for class org.codehaus.activemq.message.ActiveMQMessageWriter
 
ActiveMQObjectMessage - class org.codehaus.activemq.message.ActiveMQObjectMessage.
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.codehaus.activemq.message.ActiveMQObjectMessage
 
ActiveMQObjectMessageReader - class org.codehaus.activemq.message.ActiveMQObjectMessageReader.
Reads a Message object to a Stream
ActiveMQObjectMessageReader() - Constructor for class org.codehaus.activemq.message.ActiveMQObjectMessageReader
 
ActiveMQObjectMessageWriter - class org.codehaus.activemq.message.ActiveMQObjectMessageWriter.
Writes a Message object to a Stream
ActiveMQObjectMessageWriter() - Constructor for class org.codehaus.activemq.message.ActiveMQObjectMessageWriter
 
ActiveMQPollingEndpointWorker - class org.codehaus.activemq.ra.ActiveMQPollingEndpointWorker.
 
ActiveMQPollingEndpointWorker(ActiveMQResourceAdapter, ActiveMQEndpointActivationKey) - Constructor for class org.codehaus.activemq.ra.ActiveMQPollingEndpointWorker
 
ActiveMQPollingEndpointWorker.InboundEndpointWork - class org.codehaus.activemq.ra.ActiveMQPollingEndpointWorker.InboundEndpointWork.
 
ActiveMQPollingEndpointWorker.InboundEndpointWork(ActiveMQSession, MessageEndpoint, CircularQueue) - Constructor for class org.codehaus.activemq.ra.ActiveMQPollingEndpointWorker.InboundEndpointWork
 
ActiveMQPrefetchPolicy - class org.codehaus.activemq.ActiveMQPrefetchPolicy.
Defines the pretech message policies for different types of consumers
ActiveMQPrefetchPolicy() - Constructor for class org.codehaus.activemq.ActiveMQPrefetchPolicy
Initialize default prefetch policies
ActiveMQQueue - class org.codehaus.activemq.message.ActiveMQQueue.
A Queue object encapsulates a provider-specific queue name.
ActiveMQQueue() - Constructor for class org.codehaus.activemq.message.ActiveMQQueue
Default constructor for an ActiveMQQueue Destination
ActiveMQQueue(String) - Constructor for class org.codehaus.activemq.message.ActiveMQQueue
Construct a named ActiveMQQueue Destination
ActiveMQQueueBrowser - class org.codehaus.activemq.ActiveMQQueueBrowser.
A client uses a QueueBrowser object to look at messages on a queue without removing them.
ActiveMQQueueBrowser(ActiveMQSession, ActiveMQDestination, String, int) - Constructor for class org.codehaus.activemq.ActiveMQQueueBrowser
Constructor for an ActiveMQQueueBrowser - used internally
ActiveMQQueueReceiver - class org.codehaus.activemq.ActiveMQQueueReceiver.
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.codehaus.activemq.ActiveMQQueueReceiver
 
ActiveMQQueueSender - class org.codehaus.activemq.ActiveMQQueueSender.
A client uses a QueueSender object to send messages to a queue.
ActiveMQQueueSender(ActiveMQSession, ActiveMQDestination) - Constructor for class org.codehaus.activemq.ActiveMQQueueSender
 
ActiveMQResourceAdapter - class org.codehaus.activemq.ra.ActiveMQResourceAdapter.
Knows how to connect to one ActiveMQ server.
ActiveMQResourceAdapter() - Constructor for class org.codehaus.activemq.ra.ActiveMQResourceAdapter
 
ActiveMQResourceAdapter(ConnectionFactory) - Constructor for class org.codehaus.activemq.ra.ActiveMQResourceAdapter
 
ActiveMQSession - class org.codehaus.activemq.ActiveMQSession.
A Session object is a single-threaded context for producing and consuming messages.
ActiveMQSession(ActiveMQConnection, int) - Constructor for class org.codehaus.activemq.ActiveMQSession
Construct the Session
ActiveMQSessionExecutor - class org.codehaus.activemq.ActiveMQSessionExecutor.
A utility class used by the Sessionfor dispatching messages asycnronously to consumers
ActiveMQSessionExecutor(ActiveMQSession, MemoryBoundedQueue) - Constructor for class org.codehaus.activemq.ActiveMQSessionExecutor
 
ActiveMQStreamMessage - class org.codehaus.activemq.message.ActiveMQStreamMessage.
A StreamMessage object is used to send a stream of primitive types in the Java programming language.
ActiveMQStreamMessage() - Constructor for class org.codehaus.activemq.message.ActiveMQStreamMessage
 
ActiveMQStreamMessageReader - class org.codehaus.activemq.message.ActiveMQStreamMessageReader.
Reads a Message object to a Stream
ActiveMQStreamMessageReader() - Constructor for class org.codehaus.activemq.message.ActiveMQStreamMessageReader
 
ActiveMQStreamMessageWriter - class org.codehaus.activemq.message.ActiveMQStreamMessageWriter.
Writes a Message object to a Stream
ActiveMQStreamMessageWriter() - Constructor for class org.codehaus.activemq.message.ActiveMQStreamMessageWriter
 
ActiveMQTemporaryQueue - class org.codehaus.activemq.message.ActiveMQTemporaryQueue.
A TemporaryQueue object is a unique Queue object created for the duration of a Connection.
ActiveMQTemporaryQueue() - Constructor for class org.codehaus.activemq.message.ActiveMQTemporaryQueue
Default constructor for an ActiveMQTemporaryQueue Destination
ActiveMQTemporaryQueue(String) - Constructor for class org.codehaus.activemq.message.ActiveMQTemporaryQueue
Construct a named ActiveMQTemporaryQueue Destination
ActiveMQTemporaryTopic - class org.codehaus.activemq.message.ActiveMQTemporaryTopic.
A TemporaryTopic object is a unique Topic object created for the duration of a Connection.
ActiveMQTemporaryTopic() - Constructor for class org.codehaus.activemq.message.ActiveMQTemporaryTopic
Default constructor for an ActiveMQTemporaryTopic Destination
ActiveMQTemporaryTopic(String) - Constructor for class org.codehaus.activemq.message.ActiveMQTemporaryTopic
Construct a named ActiveMQTemporaryTopic Destination
ActiveMQTextMessage - class org.codehaus.activemq.message.ActiveMQTextMessage.
A TextMessage object is used to send a message containing a java.lang.String.
ActiveMQTextMessage() - Constructor for class org.codehaus.activemq.message.ActiveMQTextMessage
 
ActiveMQTextMessageReader - class org.codehaus.activemq.message.ActiveMQTextMessageReader.
Writes a ProducerInfo object to a Stream
ActiveMQTextMessageReader() - Constructor for class org.codehaus.activemq.message.ActiveMQTextMessageReader
 
ActiveMQTextMessageWriter - class org.codehaus.activemq.message.ActiveMQTextMessageWriter.
Writes a ProducerInfo object to a Stream
ActiveMQTextMessageWriter() - Constructor for class org.codehaus.activemq.message.ActiveMQTextMessageWriter
 
ActiveMQTopic - class org.codehaus.activemq.message.ActiveMQTopic.
A Topic object encapsulates a provider-specific topic name.
ActiveMQTopic() - Constructor for class org.codehaus.activemq.message.ActiveMQTopic
Default constructor for an ActiveMQTopic Destination
ActiveMQTopic(String) - Constructor for class org.codehaus.activemq.message.ActiveMQTopic
Construct a named ActiveMQTopic Destination
ActiveMQTopicPublisher - class org.codehaus.activemq.ActiveMQTopicPublisher.
A client uses a TopicPublisher object to publish messages on a topic.
ActiveMQTopicPublisher(ActiveMQSession, ActiveMQDestination) - Constructor for class org.codehaus.activemq.ActiveMQTopicPublisher
 
ActiveMQTopicSubscriber - class org.codehaus.activemq.ActiveMQTopicSubscriber.
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.codehaus.activemq.ActiveMQTopicSubscriber
 
ActiveMQVendorAdapter - class org.codehaus.activemq.axis.ActiveMQVendorAdapter.
An adapter for using ActiveMQ inside Apache Axis
ActiveMQVendorAdapter() - Constructor for class org.codehaus.activemq.axis.ActiveMQVendorAdapter
 
ActiveMQXAConnection - class org.codehaus.activemq.ActiveMQXAConnection.
The XAConnection interface extends the capability of Connection by providing an XASession (optional).
ActiveMQXAConnection(ActiveMQConnectionFactory, String, String, TransportChannel) - Constructor for class org.codehaus.activemq.ActiveMQXAConnection
 
ActiveMQXAConnection(ActiveMQConnectionFactory, String, String) - Constructor for class org.codehaus.activemq.ActiveMQXAConnection
 
ActiveMQXAConnectionFactory - class org.codehaus.activemq.ActiveMQXAConnectionFactory.
The XAConnectionFactory interface is a base interface for the XAQueueConnectionFactory and XATopicConnectionFactory interfaces.
ActiveMQXAConnectionFactory() - Constructor for class org.codehaus.activemq.ActiveMQXAConnectionFactory
 
ActiveMQXAConnectionFactory(String) - Constructor for class org.codehaus.activemq.ActiveMQXAConnectionFactory
 
ActiveMQXAConnectionFactory(String, String, String) - Constructor for class org.codehaus.activemq.ActiveMQXAConnectionFactory
 
ActiveMQXASession - class org.codehaus.activemq.ActiveMQXASession.
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) - Constructor for class org.codehaus.activemq.ActiveMQXASession
 
ActiveMQXid - class org.codehaus.activemq.message.ActiveMQXid.
A ActiveMQXid object holds the distributed transaction id that is passed around in an ActiveMQ system.
ActiveMQXid() - Constructor for class org.codehaus.activemq.message.ActiveMQXid
This constructor is only used for serialization
ActiveMQXid(Xid) - Constructor for class org.codehaus.activemq.message.ActiveMQXid
Creates a new ActiveMQXid object with the Xid data contained in xid
ActiveMQXid(int, byte[], byte[]) - Constructor for class org.codehaus.activemq.message.ActiveMQXid
 
ActiveMQXid(String) - Constructor for class org.codehaus.activemq.message.ActiveMQXid
Creates a new ActiveMQXid object.
AlreadyClosedException - exception org.codehaus.activemq.AlreadyClosedException.
An exception which is closed if you try to access a resource which has already been closed
AlreadyClosedException(String) - Constructor for class org.codehaus.activemq.AlreadyClosedException
 
AndFilter - class org.codehaus.activemq.filter.AndFilter.
Represents a logical AND operation on two filters
AndFilter(Filter, Filter) - Constructor for class org.codehaus.activemq.filter.AndFilter
 
ArithmeticExpression - class org.codehaus.activemq.filter.ArithmeticExpression.
An expression which performs an operation on two expression values
ArithmeticExpression(Expression, Expression) - Constructor for class org.codehaus.activemq.filter.ArithmeticExpression
 
AsyncProxy - class org.codehaus.activemq.util.AsyncProxy.
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.codehaus.activemq.util.AsyncProxy
 
AsyncProxy(Object, Executor, Log) - Constructor for class org.codehaus.activemq.util.AsyncProxy
 
AsyncProxy(Executor, Log) - Constructor for class org.codehaus.activemq.util.AsyncProxy
 
acknowledge() - Method in class org.codehaus.activemq.ActiveMQSession
Acknowledges all consumed messages of the session of this consumed message.
acknowledge() - Method in class org.codehaus.activemq.message.ActiveMQMessage
Acknowledges all consumed messages of the session of this consumed message.
acknowledge() - Method in interface org.codehaus.activemq.message.MessageAcknowledge
Acknowledge receipt of this message
acknowledgeMessage(BrokerClient, MessageAck) - Method in interface org.codehaus.activemq.broker.Broker
Acknowledge positively or negatively, the consumption of a message by the Message Consumer
acknowledgeMessage(BrokerClient, MessageAck) - Method in interface org.codehaus.activemq.broker.BrokerConnector
Acknowledge reciept of a message
acknowledgeMessage(BrokerClient, MessageAck) - Method in interface org.codehaus.activemq.broker.BrokerContainer
Acknowledge reciept of a message
acknowledgeMessage(BrokerClient, MessageAck) - Method in class org.codehaus.activemq.broker.impl.BrokerConnectorImpl
Acknowledge reciept of a message
acknowledgeMessage(BrokerClient, MessageAck) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
Acknowledge reciept of a message
acknowledgeMessage(BrokerClient, MessageAck) - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
Acknowledge consumption of a message by the Message Consumer
acknowledgeMessage(BrokerClient, MessageAck) - Method in interface org.codehaus.activemq.service.MessageContainerManager
Acknowledge a message as being read and consumed by the Consumer
acknowledgeMessage(BrokerClient, MessageAck) - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageManager
 
acknowledgeMessage(String) - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueSubscription
Acknowledge the receipt of a message by a consumer
acknowledgeMessage(BrokerClient, MessageAck) - Method in class org.codehaus.activemq.service.boundedvm.TransientTopicBoundedMessageManager
 
acknowledgeMessage(BrokerClient, MessageAck) - Method in class org.codehaus.activemq.service.impl.DurableQueueMessageContainerManager
Acknowledge a message as being read and consumed by the Consumer
acknowledgeMessage(BrokerClient, MessageAck) - Method in class org.codehaus.activemq.service.impl.DurableTopicMessageContainerManager
Acknowledge a message as being read and consumed byh the Consumer
acknowledgeMessage(BrokerClient, MessageAck) - Method in class org.codehaus.activemq.service.impl.ProxyMessageContainerManager
 
acknowledgeTransactedMessage(BrokerClient, String, MessageAck) - Method in interface org.codehaus.activemq.broker.Broker
Acknowledge positively or negatively, the consumption of a message within a transaction
acknowledgeTransactedMessage(BrokerClient, String, MessageAck) - Method in interface org.codehaus.activemq.broker.BrokerConnector
Acknowledge receipt of a message within a transaction context
acknowledgeTransactedMessage(BrokerClient, String, MessageAck) - Method in interface org.codehaus.activemq.broker.BrokerContainer
Acknowledge receipt of a message within a transaction context
acknowledgeTransactedMessage(BrokerClient, String, MessageAck) - Method in class org.codehaus.activemq.broker.impl.BrokerConnectorImpl
Acknowledge receipt of a message within a transaction context
acknowledgeTransactedMessage(BrokerClient, String, MessageAck) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
Acknowledge receipt of a message within a transaction context
acknowledgeTransactedMessage(BrokerClient, String, MessageAck) - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
Acknowledge consumption of a message within a transaction
acknowledgeTransactedMessage(BrokerClient, String, MessageAck) - Method in interface org.codehaus.activemq.service.MessageContainerManager
This is a hook to notify the dispatcher for the clients subscription that we have acknowledged a message within a transaction but before the commit - so the message is not really being acknowledged here but this method is intended to be a hook to let the dispatcher know that we can now send another message to the client.
acknowledgeTransactedMessage(BrokerClient, String, MessageAck) - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageManager
 
acknowledgeTransactedMessage(BrokerClient, String, MessageAck) - Method in class org.codehaus.activemq.service.boundedvm.TransientTopicBoundedMessageManager
 
acknowledgeTransactedMessage(BrokerClient, String, MessageAck) - Method in class org.codehaus.activemq.service.impl.DurableQueueMessageContainerManager
 
acknowledgeTransactedMessage(BrokerClient, String, MessageAck) - Method in class org.codehaus.activemq.service.impl.DurableTopicMessageContainerManager
 
acknowledgeTransactedMessage(BrokerClient, String, MessageAck) - Method in class org.codehaus.activemq.service.impl.ProxyMessageContainerManager
 
activate(int) - Method in class org.codehaus.activemq.journal.impl.Segment
 
activateNextSegment() - Method in class org.codehaus.activemq.journal.impl.LogFile
 
activateOptions() - Method in class org.codehaus.activemq.util.JmsLogAppenderSupport
 
activeSessions - Variable in class org.codehaus.activemq.ra.ActiveMQAsfEndpointWorker.ServerSessionPoolImpl
 
activeSubscriptions - Variable in class org.codehaus.activemq.service.impl.DurableQueueMessageContainerManager
 
activeSubscriptions - Variable in class org.codehaus.activemq.service.impl.DurableTopicMessageContainerManager
 
adapter - Variable in class org.codehaus.activemq.ra.ActiveMQBaseEndpointWorker
 
adapter - Variable in class org.codehaus.activemq.store.jdbc.JDBCMessageStore
 
add(String[], int, Object) - Method in class org.codehaus.activemq.filter.DestinationMapNode
 
add(long) - Method in class org.codehaus.activemq.management.CountStatisticImpl
 
add(Object) - Method in interface org.codehaus.activemq.service.QueueList
Appends the specified element to the end of this list.
add(int, Object) - Method in interface org.codehaus.activemq.service.QueueList
Inserts the specified element at the specified position in this list.
add(Object) - Method in class org.codehaus.activemq.service.impl.DefaultQueueList
 
add(int, Object) - Method in class org.codehaus.activemq.service.impl.DefaultQueueList
 
add(Object) - Method in class org.codehaus.activemq.service.impl.QueueListSupport
 
add(int, Object) - Method in class org.codehaus.activemq.service.impl.QueueListSupport
 
addActiveSubscription(BrokerClient, Subscription) - Method in interface org.codehaus.activemq.service.Dispatcher
Add an active subscription
addActiveSubscription(BrokerClient, Subscription) - Method in class org.codehaus.activemq.service.impl.DispatchWorker
Add an active subscription
addActiveSubscription(BrokerClient, Subscription) - Method in class org.codehaus.activemq.service.impl.DispatcherImpl
Add an active subscription
addBefore(Object, QueueListEntry) - Method in interface org.codehaus.activemq.service.QueueList
Insert an Entry before this entry
addBefore(Object, QueueListEntry) - Method in class org.codehaus.activemq.service.impl.DefaultQueueList
 
addBefore(Object, QueueListEntry) - Method in class org.codehaus.activemq.service.impl.QueueListSupport
 
addBrokerVisited(String) - Method in class org.codehaus.activemq.message.AbstractPacket
As the packet passes through the broker add the broker to the visited list
addBrokerVisited(String) - Method in interface org.codehaus.activemq.message.Packet
As the packet passes through the broker add the broker to the visited list
addCapacityEventListener(CapacityMonitorEventListener) - Method in class org.codehaus.activemq.capacity.BasicCapacityMonitor
Add a CapacityMonitorEventListener
addCapacityEventListener(CapacityMonitorEventListener) - Method in interface org.codehaus.activemq.capacity.CapacityMonitor
Add a CapacityMonitorEventListener
addCapacityEventListener(CapacityMonitorEventListener) - Method in class org.codehaus.activemq.capacity.DelegateCapacityMonitor
Add a CapacityEventListener
addChannel(String, Map) - Method in class org.codehaus.activemq.transport.DiscoveryNetworkConnector
 
addClient(BrokerClient, ConnectionInfo) - Method in interface org.codehaus.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.codehaus.activemq.broker.impl.BrokerConnectorImpl
 
addClient(BrokerClient, ConnectionInfo) - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
addClient(TransportChannel) - Method in interface org.codehaus.activemq.transport.TransportChannelListener
Called when a new channel is added to a server
addClient(TransportChannel) - Method in class org.codehaus.activemq.transport.TransportServerChannelSupport
 
addConnection(ActiveMQConnection) - Method in class org.codehaus.activemq.management.JMSStatsImpl
 
addConnectionConsumer(ActiveMQConnectionConsumer) - Method in class org.codehaus.activemq.ActiveMQConnection
Add a ConnectionConsumer
addConnectionEventListener(ConnectionEventListener) - Method in class org.codehaus.activemq.ra.ActiveMQManagedConnection
 
addConnector(BrokerConnector) - Method in interface org.codehaus.activemq.broker.BrokerContainer
Called when a new connector is added to this container
addConnector(String) - Method in interface org.codehaus.activemq.broker.BrokerContainer
Adds a new transport connector for the given bind address
addConnector(String, WireFormat) - Method in interface org.codehaus.activemq.broker.BrokerContainer
Adds a new transport connector for the given bind address and wire format
addConnector(TransportServerChannel) - Method in interface org.codehaus.activemq.broker.BrokerContainer
Adds a new transport connector for the given transportConnector
addConnector(BrokerConnector) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
 
addConnector(String) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
 
addConnector(String, WireFormat) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
 
addConnector(TransportServerChannel) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
 
addConsumer(ActiveMQMessageConsumer) - Method in class org.codehaus.activemq.ActiveMQSession
 
addConsumer(Filter, ConsumerInfo, BrokerClient) - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
Add a consumer to dispatch messages to
addConsumer(Filter, ConsumerInfo) - Method in class org.codehaus.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
Add a consumer to dispatch messages to
addConsumerInfoListener(ConsumerInfoListener) - Method in interface org.codehaus.activemq.broker.Broker
Add a ConsumerInfoListener to the Broker
addConsumerInfoListener(ConsumerInfoListener) - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
Add a ConsumerInfoListener to the Broker
addEscapes(String) - Static method in class org.codehaus.activemq.selector.TokenMgrError
Replaces unprintable characters by their espaced (or unicode escaped) equivalents in the given string
addExpression() - Method in class org.codehaus.activemq.selector.SelectorParser
 
addExpressionListner(Expression, MultiExpressionEvaluator.ExpressionListener) - Method in class org.codehaus.activemq.filter.MultiExpressionEvaluator
Adds an ExpressionListener to a given expression.
addFirst(Object) - Method in interface org.codehaus.activemq.service.QueueList
Inserts the given element at the beginning of this list.
addFirst(Object) - Method in class org.codehaus.activemq.service.impl.DefaultQueueList
 
addFirst(Object) - Method in class org.codehaus.activemq.service.impl.QueueListSupport
 
addKeyValuePair(Map, String) - Static method in class org.codehaus.activemq.util.URIHelper
 
addLast(Object) - Method in interface org.codehaus.activemq.service.QueueList
Appends the given element to the end of this list.
addLast(Object) - Method in class org.codehaus.activemq.service.impl.DefaultQueueList
 
addLast(Object) - Method in class org.codehaus.activemq.service.impl.QueueListSupport
 
addMessage(ActiveMQMessage) - Method in interface org.codehaus.activemq.service.MessageContainer
Add an ActiveMQMessage to the message container
addMessage(MessageContainer, ActiveMQMessage) - Method in interface org.codehaus.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.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
 
addMessage(ActiveMQMessage) - Method in class org.codehaus.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
 
addMessage(ActiveMQMessage) - Method in class org.codehaus.activemq.service.impl.DurableQueueMessageContainer
 
addMessage(ActiveMQMessage) - Method in class org.codehaus.activemq.service.impl.DurableTopicMessageContainer
 
addMessage(MessageContainer, ActiveMQMessage) - Method in class org.codehaus.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.codehaus.activemq.store.MessageStore
Adds a message to the message store
addMessage(ActiveMQMessage) - Method in class org.codehaus.activemq.store.bdb.BDbMessageStore
 
addMessage(ActiveMQMessage) - Method in class org.codehaus.activemq.store.bdbn.BDbMessageStore
 
addMessage(ActiveMQMessage) - Method in class org.codehaus.activemq.store.cache.CacheMessageStore
Add the meessage to the long term store and cache it.
addMessage(ActiveMQMessage) - Method in class org.codehaus.activemq.store.howl.HowlMessageStore
This method is synchronized to ensure that only 1 thread can write to the log and cache and possibly checkpoint at once, to preserve order across the transaction log, cache and checkpointStore.
addMessage(ActiveMQMessage) - Method in class org.codehaus.activemq.store.jdbc.JDBCMessageStore
 
addMessage(ActiveMQMessage) - Method in class org.codehaus.activemq.store.jdbm.JdbmMessageStore
 
addMessage(ActiveMQMessage) - Method in class org.codehaus.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 class org.codehaus.activemq.store.vm.VMMessageStore
 
addMessageConsumer(BrokerClient, ConsumerInfo) - Method in interface org.codehaus.activemq.broker.Broker
Add an active message consumer, which could be rejected due to authorization
addMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
Add an active message consumer
addMessageConsumer(BrokerClient, ConsumerInfo) - Method in interface org.codehaus.activemq.service.MessageContainerManager
 
addMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageManager
Add a consumer if appropiate
addMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.codehaus.activemq.service.boundedvm.TransientTopicBoundedMessageManager
Add a consumer if appropiate
addMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.codehaus.activemq.service.impl.DurableQueueMessageContainerManager
 
addMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.codehaus.activemq.service.impl.DurableTopicMessageContainerManager
 
addMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.codehaus.activemq.service.impl.InitialImageMessageContainerManager
 
addMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.codehaus.activemq.service.impl.ProxyMessageContainerManager
 
addMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.codehaus.activemq.service.impl.TransientTopicMessageContainerManager
 
addMessageDispatcher(ActiveMQMessageDispatcher) - Method in class org.codehaus.activemq.ActiveMQConnection
Add a Message dispatcher to receive messages from the Broker
addMessageProducer(BrokerClient, ProducerInfo) - Method in interface org.codehaus.activemq.broker.Broker
Adds a new message producer, which could be rejected due to authorization
addMessageProducer(BrokerClient, ProducerInfo) - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
addMessageToCache(ActiveMQMessage) - Method in class org.codehaus.activemq.store.howl.HowlMessageStore
Adds the given message to the cache if there is spare capacity
addNetworkChannel(String) - Method in class org.codehaus.activemq.transport.NetworkConnector
Adds a new network channel for the given URI
addNetworkChannel(NetworkChannel) - Method in class org.codehaus.activemq.transport.NetworkConnector
Adds a new network channel
addNetworkConnector(String) - Method in interface org.codehaus.activemq.broker.BrokerContainer
Adds a new network connector for the given URI
addNetworkConnector() - Method in interface org.codehaus.activemq.broker.BrokerContainer
Adds a new network connector
addNetworkConnector(NetworkConnector) - Method in interface org.codehaus.activemq.broker.BrokerContainer
Adds a new network connector
addNetworkConnector(String) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
 
addNetworkConnector() - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
 
addNetworkConnector(NetworkConnector) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
 
addPostCommitTask(TransactionTask) - Method in interface org.codehaus.activemq.service.Transaction
 
addPostCommitTask(TransactionTask) - Method in class org.codehaus.activemq.service.impl.AbstractTransaction
 
addPostRollbackTask(TransactionTask) - Method in interface org.codehaus.activemq.service.Transaction
 
addPostRollbackTask(TransactionTask) - Method in class org.codehaus.activemq.service.impl.AbstractTransaction
 
addPrePrepareTask(TransactionTask) - Method in interface org.codehaus.activemq.service.Transaction
 
addPrePrepareTask(TransactionTask) - Method in class org.codehaus.activemq.service.impl.AbstractTransaction
 
addProducer(ActiveMQMessageProducer) - Method in class org.codehaus.activemq.ActiveMQSession
 
addService(DiscoveryEvent) - Method in interface org.codehaus.activemq.transport.DiscoveryListener
 
addService(DiscoveryEvent) - Method in class org.codehaus.activemq.transport.DiscoveryNetworkConnector
 
addService(DiscoveryEvent) - Method in class org.codehaus.activemq.transport.DiscoveryTransportChannel
 
addService(JmDNS, String, String) - Method in class org.codehaus.activemq.transport.zeroconf.ZeroconfDiscoveryAgent
 
addSession(ActiveMQSession) - Method in class org.codehaus.activemq.ActiveMQConnection
Used internally for adding Sessions to the Connection
addShutdownHook() - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
 
addStatistic(String, Statistic) - Method in class org.codehaus.activemq.management.StatsImpl
 
addTime(long) - Method in class org.codehaus.activemq.management.TimeStatisticImpl
 
addToEnvironment(String, Object) - Method in class org.codehaus.activemq.jndi.ReadOnlyContext
 
addTransportStatusEventListener(TransportStatusEventListener) - Method in interface org.codehaus.activemq.transport.TransportChannel
Add a listener for changes in a channels status
addTransportStatusEventListener(TransportStatusEventListener) - Method in class org.codehaus.activemq.transport.TransportChannelSupport
Add a listener for changes in a channels status
addVendorConnectionFactoryProperties(JMSURLHelper, HashMap) - Method in class org.codehaus.activemq.axis.ActiveMQVendorAdapter
 
add_escapes(String) - Method in class org.codehaus.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.
adjustBeginLineColumn(int, int) - Method in class org.codehaus.activemq.selector.SimpleCharStream
Method to adjust line and column numbers for the start of a token.
allocateConnection(ManagedConnectionFactory, ConnectionRequestInfo) - Method in class org.codehaus.activemq.ra.DefaultConnectionManager
 
allocateConnection(ManagedConnectionFactory, ConnectionRequestInfo) - Method in class org.codehaus.activemq.ra.SimpleConnectionManager
 
andExpression() - Method in class org.codehaus.activemq.selector.SelectorParser
 
append(Record) - Method in class org.codehaus.activemq.journal.impl.BatchedWrite
 
append(LoggingEvent) - Method in class org.codehaus.activemq.util.JmsLogAppenderSupport
 
appendAndForce(BatchedWrite) - Method in class org.codehaus.activemq.journal.impl.LogFile
 
appendDescendantValues(Set) - Method in class org.codehaus.activemq.filter.DestinationMapNode
 
appendFieldDescription(StringBuffer) - Method in class org.codehaus.activemq.management.BoundaryStatisticImpl
 
appendFieldDescription(StringBuffer) - Method in class org.codehaus.activemq.management.BoundedRangeStatisticImpl
 
appendFieldDescription(StringBuffer) - Method in class org.codehaus.activemq.management.CountStatisticImpl
 
appendFieldDescription(StringBuffer) - Method in class org.codehaus.activemq.management.RangeStatisticImpl
 
appendFieldDescription(StringBuffer) - Method in class org.codehaus.activemq.management.StatisticImpl
 
appendFieldDescription(StringBuffer) - Method in class org.codehaus.activemq.management.TimeStatisticImpl
 
appendMatchingValues(Set, String[], int) - Method in class org.codehaus.activemq.filter.DestinationMapNode
 
appendMatchingWildcards(Set, String[], int) - Method in class org.codehaus.activemq.filter.DestinationMapNode
 
appendParametersToMessage(HttpServletRequest, TextMessage) - Method in class org.codehaus.activemq.web.MessageServletSupport
 
asBoolean(int) - Method in class org.codehaus.activemq.filter.ComparisonExpression
 
asBoolean(String) - Static method in class org.codehaus.activemq.web.MessageServletSupport
 
asBytes() - Method in class org.codehaus.activemq.service.impl.QueueListSupport.Header
 
asBytes() - Method in class org.codehaus.activemq.service.impl.QueueListSupport.Node
 
asBytes(long) - Static method in class org.codehaus.activemq.store.bdb.BDbHelper
 
asBytes(Long) - Static method in class org.codehaus.activemq.store.bdb.BDbHelper
 
asBytes(ActiveMQMessage) - Method in class org.codehaus.activemq.store.bdb.BDbMessageStore
 
asBytes(String) - Method in class org.codehaus.activemq.store.bdb.BDbMessageStore
 
asBytes(ActiveMQMessage) - Method in class org.codehaus.activemq.store.bdbn.BDbMessageStore
 
asBytes(String) - Method in class org.codehaus.activemq.store.bdbn.BDbMessageStore
 
asLong(String) - Method in class org.codehaus.activemq.web.MessageServletSupport
 
asNumber(Object) - Method in class org.codehaus.activemq.filter.ArithmeticExpression
 
asTextWireFormat(WireFormat) - Method in class org.codehaus.activemq.transport.http.HttpTransportChannelFactory
 
associateConnection(Object) - Method in class org.codehaus.activemq.ra.ActiveMQManagedConnection
 
asyncSend(Packet) - Method in interface org.codehaus.activemq.transport.TransportChannel
Asynchronously send a Packet
asyncSend(Packet) - Method in class org.codehaus.activemq.transport.composite.CompositeTransportChannel
 
asyncSend(Packet) - Method in class org.codehaus.activemq.transport.ember.EmberTransportChannel
Asynchronously send a Packet
asyncSend(Packet) - Method in class org.codehaus.activemq.transport.gnet.GTransportChannel
Asynchronously send a Packet
asyncSend(Packet) - Method in class org.codehaus.activemq.transport.http.HttpClientTransportChannel
 
asyncSend(Packet) - Method in class org.codehaus.activemq.transport.http.HttpServerTransportChannel
 
asyncSend(Packet) - Method in class org.codehaus.activemq.transport.http.HttpTransportChannel
 
asyncSend(Packet) - Method in class org.codehaus.activemq.transport.jgroups.JGroupsTransportChannel
Asynchronously send a Packet
asyncSend(Packet) - Method in class org.codehaus.activemq.transport.jrms.JRMSTransportChannel
Asynchronously send a Packet
asyncSend(Packet) - Method in class org.codehaus.activemq.transport.reliable.ReliableTransportChannel
 
asyncSend(Packet) - Method in class org.codehaus.activemq.transport.tcp.TcpTransportChannel
Asynchronously send a Packet
asyncSend(Packet) - Method in class org.codehaus.activemq.transport.udp.UdpTransportChannel
Asynchronously send a Packet
asyncSend(Packet) - Method in class org.codehaus.activemq.transport.vm.VmTransportChannel
Asynchronously send a Packet
asyncSendPacket(Packet) - Method in class org.codehaus.activemq.ActiveMQConnection
send a Packet through the Connection - for internal use only
asyncSendPacket(Packet, boolean) - Method in class org.codehaus.activemq.ActiveMQConnection
send a Packet through the Connection - for internal use only
attemptToConnect(URI) - Method in class org.codehaus.activemq.transport.composite.CompositeTransportChannel
 
authorizeConnection(BrokerClient, ConnectionInfo) - Method in interface org.codehaus.activemq.security.SecurityAdapter
Authenticates the connection and authorizes it for use with this Message Broker
authorizeConsumer(BrokerClient, ConsumerInfo) - Method in interface org.codehaus.activemq.security.SecurityAdapter
Authorizes that the consumer can start with the given consumer information
authorizeProducer(BrokerClient, ProducerInfo) - Method in interface org.codehaus.activemq.security.SecurityAdapter
Authorizes that the prodcuer can start with the given producer information.
authorizeSendMessage(BrokerClient, ActiveMQMessage) - Method in interface org.codehaus.activemq.security.SecurityAdapter
Authorizes on a per message basis whether or not the client is allowed to send the given message.
available() - Method in class org.codehaus.activemq.message.util.WireByteArrayInputStream
 
available - Variable in class org.codehaus.activemq.selector.SimpleCharStream
 

B

BACKLOG - Static variable in class org.codehaus.activemq.transport.gnet.GTransportServerChannel
 
BACKLOG - Static variable in class org.codehaus.activemq.transport.tcp.SfTransportServerChannelFactory
 
BDbHelper - class org.codehaus.activemq.store.bdb.BDbHelper.
Some helper factory methods for creating default configured Berkeley DB objects
BDbHelper() - Constructor for class org.codehaus.activemq.store.bdb.BDbHelper
 
BDbHelper - class org.codehaus.activemq.store.bdbn.BDbHelper.
Some helper factory methods for creating default configured Berkeley DB objects
BDbHelper() - Constructor for class org.codehaus.activemq.store.bdbn.BDbHelper
 
BDbMessageStore - class org.codehaus.activemq.store.bdb.BDbMessageStore.
 
BDbMessageStore(Database, SecondaryDatabase, SecondaryConfig, SequenceNumberCreator, WireFormat) - Constructor for class org.codehaus.activemq.store.bdb.BDbMessageStore
 
BDbMessageStore - class org.codehaus.activemq.store.bdbn.BDbMessageStore.
An implementation of MessageStore using native C Berkeley DB
BDbMessageStore() - Constructor for class org.codehaus.activemq.store.bdbn.BDbMessageStore
 
BDbPersistenceAdapter - class org.codehaus.activemq.store.bdb.BDbPersistenceAdapter.
A PersistenceAdapter implementation using Berkeley DB Java Edition
BDbPersistenceAdapter() - Constructor for class org.codehaus.activemq.store.bdb.BDbPersistenceAdapter
 
BDbPersistenceAdapter(File) - Constructor for class org.codehaus.activemq.store.bdb.BDbPersistenceAdapter
 
BDbPersistenceAdapter(Environment, WireFormat) - Constructor for class org.codehaus.activemq.store.bdb.BDbPersistenceAdapter
 
BDbPersistenceAdapter(Environment, WireFormat, DatabaseConfig, TransactionConfig) - Constructor for class org.codehaus.activemq.store.bdb.BDbPersistenceAdapter
 
BDbPersistenceAdapter - class org.codehaus.activemq.store.bdbn.BDbPersistenceAdapter.
 
BDbPersistenceAdapter(DbEnv) - Constructor for class org.codehaus.activemq.store.bdbn.BDbPersistenceAdapter
 
BDbPreparedTransactionStore - class org.codehaus.activemq.store.bdb.BDbPreparedTransactionStore.
 
BDbPreparedTransactionStore(Database) - Constructor for class org.codehaus.activemq.store.bdb.BDbPreparedTransactionStore
 
BDbTopicMessageStore - class org.codehaus.activemq.store.bdb.BDbTopicMessageStore.
 
BDbTopicMessageStore(Database, SecondaryDatabase, SecondaryConfig, SequenceNumberCreator, WireFormat, Database) - Constructor for class org.codehaus.activemq.store.bdb.BDbTopicMessageStore
 
BDbTopicMessageStore - class org.codehaus.activemq.store.bdbn.BDbTopicMessageStore.
An implementation of TopicMessageStore using native C Berkeley DB
BDbTopicMessageStore() - Constructor for class org.codehaus.activemq.store.bdbn.BDbTopicMessageStore
 
BETWEEN - Static variable in interface org.codehaus.activemq.selector.SelectorParserConstants
 
BLOCK_COMMENT - Static variable in interface org.codehaus.activemq.selector.SelectorParserConstants
 
BOOLEAN - Static variable in class org.codehaus.activemq.message.ActiveMQMessage
 
BROKERS_VISITED_INDEX - Static variable in class org.codehaus.activemq.message.AbstractPacket
 
BROKER_NAME_INDEX - Static variable in class org.codehaus.activemq.message.ActiveMQMessage
 
BROKER_URL - Static variable in class org.codehaus.activemq.axis.ActiveMQVendorAdapter
The URL to connect to the broker
BYTE - Static variable in class org.codehaus.activemq.message.ActiveMQMessage
 
BYTES - Static variable in class org.codehaus.activemq.message.ActiveMQMessage
 
BYTE_SIZE - Static variable in class org.codehaus.activemq.util.BitArray
 
BasicCapacityMonitor - class org.codehaus.activemq.capacity.BasicCapacityMonitor.
BasicCapacityMonitor implementation
BasicCapacityMonitor(String, long) - Constructor for class org.codehaus.activemq.capacity.BasicCapacityMonitor
Construct a CapacityMonitor
BatchedWrite - class org.codehaus.activemq.journal.impl.BatchedWrite.
This contains all the data needed to write and force a list of records to a LogFile.
BatchedWrite(ByteBuffer) - Constructor for class org.codehaus.activemq.journal.impl.BatchedWrite
 
BeanUtils - class org.codehaus.activemq.util.BeanUtils.
Some bean utility methods
BeanUtils() - Constructor for class org.codehaus.activemq.util.BeanUtils
 
BeginToken() - Method in class org.codehaus.activemq.selector.SimpleCharStream
 
BinaryExpression - class org.codehaus.activemq.filter.BinaryExpression.
An expression which performs an operation on two expression values.
BinaryExpression(Expression, Expression) - Constructor for class org.codehaus.activemq.filter.BinaryExpression
 
BitArray - class org.codehaus.activemq.util.BitArray.
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.codehaus.activemq.util.BitArray
 
BitArrayBin - class org.codehaus.activemq.util.BitArrayBin.
Holder for many bitArrays - used for message audit
BitArrayBin(int) - Constructor for class org.codehaus.activemq.util.BitArrayBin
Create a BitArrayBin to a certain window size (number of messages to keep)
BlobJDBCAdapter - class org.codehaus.activemq.store.jdbc.adapter.BlobJDBCAdapter.
This JDBCAdapter inserts and extracts BLOB data using the getBlob()/setBlob() operations.
BlobJDBCAdapter() - Constructor for class org.codehaus.activemq.store.jdbc.adapter.BlobJDBCAdapter
 
BlobJDBCAdapter(StatementProvider) - Constructor for class org.codehaus.activemq.store.jdbc.adapter.BlobJDBCAdapter
 
BooleanExpression - interface org.codehaus.activemq.filter.BooleanExpression.
A BooleanExpression is an expression that always produces a Boolean result.
BoundaryStatisticImpl - class org.codehaus.activemq.management.BoundaryStatisticImpl.
A boundary statistic implementation
BoundaryStatisticImpl(String, String, String, long, long) - Constructor for class org.codehaus.activemq.management.BoundaryStatisticImpl
 
BoundedPacketQueue - interface org.codehaus.activemq.message.util.BoundedPacketQueue.
BoundedPacketQueue
BoundedRangeStatisticImpl - class org.codehaus.activemq.management.BoundedRangeStatisticImpl.
A bounded range statistic implementation
BoundedRangeStatisticImpl(String, String, String, long, long) - Constructor for class org.codehaus.activemq.management.BoundedRangeStatisticImpl
 
Broker - interface org.codehaus.activemq.broker.Broker.
The Message Broker which routes messages, maintains subscriptions and connections, acknowlegdges messages and handles transactions.
BrokerClient - interface org.codehaus.activemq.broker.BrokerClient.
A Broker side proxy representing mostly outbound JMS Connnection
BrokerClientImpl - class org.codehaus.activemq.broker.impl.BrokerClientImpl.
A Broker client side proxy representing a JMS Connnection
BrokerClientImpl() - Constructor for class org.codehaus.activemq.broker.impl.BrokerClientImpl
Default Constructor of BrokerClientImpl
BrokerConnector - interface org.codehaus.activemq.broker.BrokerConnector.
The Broker is the client side interface to the JMS server
BrokerConnectorImpl - class org.codehaus.activemq.broker.impl.BrokerConnectorImpl.
An implementation of the broker (the JMS server)
BrokerConnectorImpl(BrokerContainer, String, WireFormat) - Constructor for class org.codehaus.activemq.broker.impl.BrokerConnectorImpl
Helper constructor for TCP protocol with the given bind address
BrokerConnectorImpl(BrokerContainer, TransportServerChannel) - Constructor for class org.codehaus.activemq.broker.impl.BrokerConnectorImpl
 
BrokerContainer - interface org.codehaus.activemq.broker.BrokerContainer.
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.

BrokerContainerFactory - interface org.codehaus.activemq.broker.BrokerContainerFactory.
A Factory of BrokerContainer objects
BrokerContainerFactoryImpl - class org.codehaus.activemq.broker.impl.BrokerContainerFactoryImpl.
 
BrokerContainerFactoryImpl() - Constructor for class org.codehaus.activemq.broker.impl.BrokerContainerFactoryImpl
 
BrokerContainerFactoryImpl(PersistenceAdapter) - Constructor for class org.codehaus.activemq.broker.impl.BrokerContainerFactoryImpl
 
BrokerContainerImpl - class org.codehaus.activemq.broker.impl.BrokerContainerImpl.
Represents the ActiveMQ JMS Broker which typically has one or many connectors
BrokerContainerImpl() - Constructor for class org.codehaus.activemq.broker.impl.BrokerContainerImpl
 
BrokerContainerImpl(String) - Constructor for class org.codehaus.activemq.broker.impl.BrokerContainerImpl
 
BrokerContainerImpl(String, PersistenceAdapter) - Constructor for class org.codehaus.activemq.broker.impl.BrokerContainerImpl
 
BrokerContainerImpl(String, BrokerContext) - Constructor for class org.codehaus.activemq.broker.impl.BrokerContainerImpl
 
BrokerContainerImpl(String, PersistenceAdapter, BrokerContext) - Constructor for class org.codehaus.activemq.broker.impl.BrokerContainerImpl
 
BrokerContainerImpl(Broker, BrokerContext) - Constructor for class org.codehaus.activemq.broker.impl.BrokerContainerImpl
 
BrokerContext - class org.codehaus.activemq.broker.BrokerContext.
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.codehaus.activemq.broker.BrokerContext
 
BrokerInfo - class org.codehaus.activemq.message.BrokerInfo.
Information about a connected Broker
BrokerInfo() - Constructor for class org.codehaus.activemq.message.BrokerInfo
 
BrokerInfoReader - class org.codehaus.activemq.message.BrokerInfoReader.
Reads a ConsumerInfo object from a Stream
BrokerInfoReader() - Constructor for class org.codehaus.activemq.message.BrokerInfoReader
 
BrokerInfoWriter - class org.codehaus.activemq.message.BrokerInfoWriter.
Writes a ConsumerInfo object to a Stream
BrokerInfoWriter() - Constructor for class org.codehaus.activemq.message.BrokerInfoWriter
 
ByteBufferPool - class org.codehaus.activemq.journal.impl.ByteBufferPool.
Provides a simple pool of ByteBuffer objects.
ByteBufferPool() - Constructor for class org.codehaus.activemq.journal.impl.ByteBufferPool
Creates a pool of 4 x 4 Meg ByteBuffers
ByteBufferPool(int, int) - Constructor for class org.codehaus.activemq.journal.impl.ByteBufferPool
Creates a pool of bufferCount ByteBuffers that are directly allocated being bufferSize big.
BytesJDBCAdapter - class org.codehaus.activemq.store.jdbc.adapter.BytesJDBCAdapter.
This JDBCAdapter inserts and extracts BLOB data using the setBytes()/getBytes() operations.
BytesJDBCAdapter() - Constructor for class org.codehaus.activemq.store.jdbc.adapter.BytesJDBCAdapter
 
BytesJDBCAdapter(StatementProvider) - Constructor for class org.codehaus.activemq.store.jdbc.adapter.BytesJDBCAdapter
 
backup(int) - Method in class org.codehaus.activemq.selector.SimpleCharStream
 
beginColumn - Variable in class org.codehaus.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.codehaus.activemq.ra.LocalTransactionEventListener
 
beginLine - Variable in class org.codehaus.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.
beginTransaction() - Method in interface org.codehaus.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.codehaus.activemq.store.bdb.BDbPersistenceAdapter
 
beginTransaction() - Method in class org.codehaus.activemq.store.bdbn.BDbPersistenceAdapter
 
beginTransaction() - Method in class org.codehaus.activemq.store.cache.CachePersistenceAdapter
 
beginTransaction() - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
beginTransaction() - Method in class org.codehaus.activemq.store.jdbc.JDBCPersistenceAdapter
 
beginTransaction() - Method in class org.codehaus.activemq.store.jdbm.JdbmPersistenceAdapter
 
beginTransaction() - Method in class org.codehaus.activemq.store.journal.JournalPersistenceAdapter
 
beginTransaction() - Method in class org.codehaus.activemq.store.vm.VMPersistenceAdapter
 
binaryDataType - Variable in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
bind(Name, Object) - Method in class org.codehaus.activemq.jndi.ReadOnlyContext
 
bind(String, Object) - Method in class org.codehaus.activemq.jndi.ReadOnlyContext
 
bindAddress - Variable in class org.codehaus.activemq.transport.multicast.MulticastTransportServerChannel
 
bindings - Variable in class org.codehaus.activemq.jndi.ReadOnlyContext
 
bitArray - Variable in class org.codehaus.activemq.message.AbstractPacket
 
brokerContainer - Variable in class org.codehaus.activemq.ActiveMQConnectionFactory
 
brokerName - Variable in class org.codehaus.activemq.ActiveMQConnectionFactory
 
brokerName - Variable in class org.codehaus.activemq.service.impl.SubscriptionImpl
 
brokerURL - Variable in class org.codehaus.activemq.ActiveMQConnectionFactory
 
brokerUrlInitParam - Static variable in class org.codehaus.activemq.web.WebClient
 
browser - Variable in class org.codehaus.activemq.ActiveMQMessageConsumer
 
browsers - Variable in class org.codehaus.activemq.service.impl.DurableQueueMessageContainerManager
 
bufpos - Variable in class org.codehaus.activemq.selector.SimpleCharStream
 
bufsize - Variable in class org.codehaus.activemq.selector.SimpleCharStream
 
buildBodyFromBytes() - Method in class org.codehaus.activemq.message.ActiveMQMessage
Builds the message body from data
buildChecksum(byte[]) - Static method in class org.codehaus.activemq.journal.impl.RecordFooter
 
buildFromProperties(Properties) - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
Set the properties that will represent the instance in JNDI
buildFromProperties(Properties) - Method in class org.codehaus.activemq.jndi.JNDIBaseStorable
Set the properties that will represent the instance in JNDI
buildFromProperties(Properties) - Method in class org.codehaus.activemq.message.ActiveMQDestination
Set the properties that will represent the instance in JNDI
buildPacket(Packet, DataInput) - Method in class org.codehaus.activemq.message.AbstractPacketReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in class org.codehaus.activemq.message.ActiveMQMessageReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in class org.codehaus.activemq.message.BrokerInfoReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in class org.codehaus.activemq.message.CapacityInfoReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in class org.codehaus.activemq.message.CapacityInfoRequestReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in class org.codehaus.activemq.message.ConnectionInfoReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in class org.codehaus.activemq.message.ConsumerInfoReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in class org.codehaus.activemq.message.DurableUnsubscribeReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in class org.codehaus.activemq.message.IntResponseReceiptReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in class org.codehaus.activemq.message.MessageAckReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in interface org.codehaus.activemq.message.PacketReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in class org.codehaus.activemq.message.ProducerInfoReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in class org.codehaus.activemq.message.ReceiptReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in class org.codehaus.activemq.message.ResponseReceiptReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in class org.codehaus.activemq.message.SessionInfoReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in class org.codehaus.activemq.message.TransactionInfoReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in class org.codehaus.activemq.message.WireFormatInfoReader
build a Packet instance from the data input stream
buildPacket(Packet, DataInput) - Method in class org.codehaus.activemq.message.XATransactionInfoReader
build a Packet instance from the data input stream
bulkSet(RecordHeader, byte[]) - Method in class org.codehaus.activemq.journal.impl.RecordFooter
 
bulkSet(byte, long, byte[]) - Method in class org.codehaus.activemq.journal.impl.RecordHeader
 

C

CAPACITY_INFO - Static variable in interface org.codehaus.activemq.message.Packet
Infomation about the Capacity for more Messages for either Connection/Broker
CAPACITY_INFO_REQUEST - Static variable in interface org.codehaus.activemq.message.Packet
Request infomation about the current capacity
CHAR - Static variable in class org.codehaus.activemq.message.ActiveMQMessage
 
CID_INDEX - Static variable in class org.codehaus.activemq.message.ActiveMQMessage
 
CLUSTER_NAME_INDEX - Static variable in class org.codehaus.activemq.message.ActiveMQMessage
 
COMMIT - Static variable in interface org.codehaus.activemq.message.TransactionType
Commit a transaction
COMMIT_ONE_PHASE - Static variable in interface org.codehaus.activemq.message.TransactionType
Do a one phase commit...
CONNECTED - Static variable in class org.codehaus.activemq.transport.TransportStatusEvent
The channel has been intially and successfully connected
CONSUMER_DISPATCH_ASYNC - Static variable in class org.codehaus.activemq.ActiveMQSession
 
CONSUMER_DISPATCH_SYNC - Static variable in class org.codehaus.activemq.ActiveMQSession
 
CONSUMER_DISPATCH_UNSET - Static variable in class org.codehaus.activemq.ActiveMQSession
 
CONSUMER_INFO - Static variable in interface org.codehaus.activemq.message.Packet
Consumer Infomation
CORRELATION_INDEX - Static variable in class org.codehaus.activemq.message.ActiveMQMessage
Message flag indexes (used for writing/reading to/from a Stream
CRC32_CHECKSUM_ALGORITHIM - Static variable in class org.codehaus.activemq.journal.impl.RecordFooter
 
CacheMessageStore - class org.codehaus.activemq.store.cache.CacheMessageStore.
A MessageStore that uses an in memory cache to speed up getMessage() method calls.
CacheMessageStore(CachePersistenceAdapter, MessageStore, MessageCache) - Constructor for class org.codehaus.activemq.store.cache.CacheMessageStore
 
CacheMessageStoreAware - interface org.codehaus.activemq.store.cache.CacheMessageStoreAware.
Other MessageStores that whish to be notified when they are being cached by a CacheMessageStore should implement the CacheMessageStoreAware interface.
CachePersistenceAdapter - class org.codehaus.activemq.store.cache.CachePersistenceAdapter.
Implements a PersistenceAdapter designed to to speed up access to recently added messages by using a MessageCache .
CachePersistenceAdapter() - Constructor for class org.codehaus.activemq.store.cache.CachePersistenceAdapter
 
CachePersistenceAdapter(PersistenceAdapter) - Constructor for class org.codehaus.activemq.store.cache.CachePersistenceAdapter
 
CacheTopicMessageStore - class org.codehaus.activemq.store.cache.CacheTopicMessageStore.
A MessageStore that uses an in memory cache to speed up getMessage() method calls.
CacheTopicMessageStore(CachePersistenceAdapter, TopicMessageStore, MessageCache) - Constructor for class org.codehaus.activemq.store.cache.CacheTopicMessageStore
 
CachingStatementProvider - class org.codehaus.activemq.store.jdbc.adapter.CachingStatementProvider.
A StatementProvider filter that caches the responses of the filtered StatementProvider.
CachingStatementProvider(StatementProvider) - Constructor for class org.codehaus.activemq.store.jdbc.adapter.CachingStatementProvider
 
Callback - interface org.codehaus.activemq.util.Callback.
A simple callback object used by the TransactionTemplate and ExceptionTemplate objects to provide automatic transactional or exception handling blocks.
CapacityInfo - class org.codehaus.activemq.message.CapacityInfo.
Infomation about the Capacity for more messages for a Connection/Broker
CapacityInfo() - Constructor for class org.codehaus.activemq.message.CapacityInfo
 
CapacityInfoReader - class org.codehaus.activemq.message.CapacityInfoReader.
Reads a CapacityInfo object from a Stream
CapacityInfoReader() - Constructor for class org.codehaus.activemq.message.CapacityInfoReader
 
CapacityInfoRequest - class org.codehaus.activemq.message.CapacityInfoRequest.
Request nfomation about the Capacity for more messages for a Connection/Broker
CapacityInfoRequest() - Constructor for class org.codehaus.activemq.message.CapacityInfoRequest
 
CapacityInfoRequestReader - class org.codehaus.activemq.message.CapacityInfoRequestReader.
Reads a CapacityInfoRequest object from a Stream
CapacityInfoRequestReader() - Constructor for class org.codehaus.activemq.message.CapacityInfoRequestReader
 
CapacityInfoRequestWriter - class org.codehaus.activemq.message.CapacityInfoRequestWriter.
Writes a CapacityInfoRequest object to a Stream
CapacityInfoRequestWriter() - Constructor for class org.codehaus.activemq.message.CapacityInfoRequestWriter
 
CapacityInfoWriter - class org.codehaus.activemq.message.CapacityInfoWriter.
Writes a CapacityInfo object to a Stream
CapacityInfoWriter() - Constructor for class org.codehaus.activemq.message.CapacityInfoWriter
 
CapacityMonitor - interface org.codehaus.activemq.capacity.CapacityMonitor.
Fires CapacityChangedEvents
CapacityMonitor.BasicCapacityMonitor - class org.codehaus.activemq.capacity.CapacityMonitor.BasicCapacityMonitor.
A CapacityMonitor holds percentage values for some resource that has a capacity - e.g.
CapacityMonitor.BasicCapacityMonitor() - Constructor for class org.codehaus.activemq.capacity.CapacityMonitor.BasicCapacityMonitor
 
CapacityMonitorEvent - class org.codehaus.activemq.capacity.CapacityMonitorEvent.
A CapacityMonitorEvent is raised to notify that a change has occurred to the capacity of a CapacityMonitor
CapacityMonitorEvent() - Constructor for class org.codehaus.activemq.capacity.CapacityMonitorEvent
Default Constructor
CapacityMonitorEvent(String, int) - Constructor for class org.codehaus.activemq.capacity.CapacityMonitorEvent
 
CapacityMonitorEventListener - interface org.codehaus.activemq.capacity.CapacityMonitorEventListener.
A listener for CapacityChangedEvents
CircularQueue - class org.codehaus.activemq.ra.CircularQueue.
 
CircularQueue(int, SynchronizedBoolean) - Constructor for class org.codehaus.activemq.ra.CircularQueue
 
ComparisonExpression - class org.codehaus.activemq.filter.ComparisonExpression.
A filter performing a comparison of two objects
ComparisonExpression(Expression, Expression) - Constructor for class org.codehaus.activemq.filter.ComparisonExpression
 
ComparisonExpression.LikeExpression - class org.codehaus.activemq.filter.ComparisonExpression.LikeExpression.
 
ComparisonExpression.LikeExpression(Expression, String, int) - Constructor for class org.codehaus.activemq.filter.ComparisonExpression.LikeExpression
 
CompositeDestinationFilter - class org.codehaus.activemq.filter.CompositeDestinationFilter.
A DestinationFilter used for composite destinations
CompositeDestinationFilter(ActiveMQDestination) - Constructor for class org.codehaus.activemq.filter.CompositeDestinationFilter
 
CompositeTransportChannel - class org.codehaus.activemq.transport.composite.CompositeTransportChannel.
A Compsite implementation of a TransportChannel
CompositeTransportChannel(WireFormat) - Constructor for class org.codehaus.activemq.transport.composite.CompositeTransportChannel
 
CompositeTransportChannel(WireFormat, List) - Constructor for class org.codehaus.activemq.transport.composite.CompositeTransportChannel
 
CompositeTransportChannelFactory - class org.codehaus.activemq.transport.composite.CompositeTransportChannelFactory.
A Composite implementation of a TransportChannelFactory
CompositeTransportChannelFactory() - Constructor for class org.codehaus.activemq.transport.composite.CompositeTransportChannelFactory
 
ConfigurationException - exception org.codehaus.activemq.ConfigurationException.
An exception thrown when a service is not correctly configured
ConfigurationException(String) - Constructor for class org.codehaus.activemq.ConfigurationException
 
ConfigurationParseException - exception org.codehaus.activemq.spring.ConfigurationParseException.
An exception that is thrown if a configuration resource could not be parsed.
ConfigurationParseException(Resource, Throwable) - Constructor for class org.codehaus.activemq.spring.ConfigurationParseException
 
ConnectionInfo - class org.codehaus.activemq.message.ConnectionInfo.
Describes a Connection
ConnectionInfo() - Constructor for class org.codehaus.activemq.message.ConnectionInfo
 
ConnectionInfoReader - class org.codehaus.activemq.message.ConnectionInfoReader.
Reads a ConnnectionInfo object from a Stream
ConnectionInfoReader() - Constructor for class org.codehaus.activemq.message.ConnectionInfoReader
 
ConnectionInfoWriter - class org.codehaus.activemq.message.ConnectionInfoWriter.
Writes a ConsumerInfo object to a Stream
ConnectionInfoWriter() - Constructor for class org.codehaus.activemq.message.ConnectionInfoWriter
 
ConnectionManager - class org.codehaus.activemq.web.ConnectionManager.
Listens to sessions closing to ensure that JMS connections are cleaned up nicely
ConnectionManager() - Constructor for class org.codehaus.activemq.web.ConnectionManager
 
ConstantExpression - class org.codehaus.activemq.filter.ConstantExpression.
Represents a constant expression
ConstantExpression(Object) - Constructor for class org.codehaus.activemq.filter.ConstantExpression
 
ConstantExpression.BooleanConstantExpression - class org.codehaus.activemq.filter.ConstantExpression.BooleanConstantExpression.
 
ConstantExpression.BooleanConstantExpression(Object) - Constructor for class org.codehaus.activemq.filter.ConstantExpression.BooleanConstantExpression
 
ConsumerInfo - class org.codehaus.activemq.message.ConsumerInfo.
Describes a Message consumer
ConsumerInfo() - Constructor for class org.codehaus.activemq.message.ConsumerInfo
 
ConsumerInfoListener - interface org.codehaus.activemq.broker.ConsumerInfoListener.
A listener for ConsumerInfo packets
ConsumerInfoReader - class org.codehaus.activemq.message.ConsumerInfoReader.
Reads a ConsumerInfo object from a Stream
ConsumerInfoReader() - Constructor for class org.codehaus.activemq.message.ConsumerInfoReader
 
ConsumerInfoWriter - class org.codehaus.activemq.message.ConsumerInfoWriter.
Writes a ConsumerInfo object to a Stream
ConsumerInfoWriter() - Constructor for class org.codehaus.activemq.message.ConsumerInfoWriter
 
CountStatisticImpl - class org.codehaus.activemq.management.CountStatisticImpl.
A count statistic implementation
CountStatisticImpl(CountStatisticImpl, String, String) - Constructor for class org.codehaus.activemq.management.CountStatisticImpl
 
CountStatisticImpl(String, String) - Constructor for class org.codehaus.activemq.management.CountStatisticImpl
 
CountStatisticImpl(String, String, String) - Constructor for class org.codehaus.activemq.management.CountStatisticImpl
 
cacheSize - Variable in class org.codehaus.activemq.store.cache.SimpleCachePersistenceAdapter
 
cachedExpressions - Variable in class org.codehaus.activemq.filter.MultiExpressionEvaluator
 
cachedHashCode - Variable in class org.codehaus.activemq.filter.MultiExpressionEvaluator.CacheExpression
 
cachedValue - Variable in class org.codehaus.activemq.filter.MultiExpressionEvaluator.CacheExpression
 
canAcceptMessages() - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueSubscription
 
canActivateNextSegment() - Method in class org.codehaus.activemq.journal.impl.LogFile
 
canProcessWireFormatVersion(int) - Method in class org.codehaus.activemq.message.DefaultWireFormat
Can this wireformat process packets of this version
canProcessWireFormatVersion(int) - Method in class org.codehaus.activemq.message.WireFormat
Can this wireformat process packets of this version
canProcessWireFormatVersion(int) - Method in interface org.codehaus.activemq.transport.TransportChannel
Can this wireformat process packets of this version
canProcessWireFormatVersion(int) - Method in class org.codehaus.activemq.transport.composite.CompositeTransportChannel
Can this wireformat process packets of this version
canProcessWireFormatVersion(int) - Method in class org.codehaus.activemq.transport.ember.EmberTransportChannel
Can this wireformat process packets of this version
canProcessWireFormatVersion(int) - Method in class org.codehaus.activemq.transport.gnet.GTransportChannel
Can this wireformat process packets of this version
canProcessWireFormatVersion(int) - Method in class org.codehaus.activemq.transport.http.HttpServerTransportChannel
Can this wireformat process packets of this version
canProcessWireFormatVersion(int) - Method in class org.codehaus.activemq.transport.http.HttpTransportChannelSupport
Can this wireformat process packets of this version
canProcessWireFormatVersion(int) - Method in class org.codehaus.activemq.transport.jabber.JabberWireFormat
Can this wireformat process packets of this version
canProcessWireFormatVersion(int) - Method in class org.codehaus.activemq.transport.jgroups.JGroupsTransportChannel
Can this wireformat process packets of this version
canProcessWireFormatVersion(int) - Method in class org.codehaus.activemq.transport.jrms.JRMSTransportChannel
Can this wireformat process packets of this version
canProcessWireFormatVersion(int) - Method in class org.codehaus.activemq.transport.tcp.TcpTransportChannel
Can this wireformat process packets of this version
canProcessWireFormatVersion(int) - Method in class org.codehaus.activemq.transport.udp.UdpTransportChannel
Can this wireformat process packets of this version
canProcessWireFormatVersion(int) - Method in class org.codehaus.activemq.transport.vm.VmTransportChannel
Can this wireformat process packets of this version
canProcessWireFormatVersion(int) - Method in class org.codehaus.activemq.transport.xstream.XStreamWireFormat
Can this wireformat process packets of this version
canRead(int) - Method in class org.codehaus.activemq.message.AbstractPacketReader
 
canRead(int) - Method in interface org.codehaus.activemq.message.PacketReader
 
canWrite(Packet) - Method in class org.codehaus.activemq.message.AbstractPacketWriter
 
canWrite(Packet) - Method in interface org.codehaus.activemq.message.PacketWriter
 
capacityChanged(CapacityMonitorEvent) - Method in class org.codehaus.activemq.ActiveMQConnection
CapacityMonitorEventListener implementation called when the capacity of a CapacityService changes
capacityChanged(CapacityMonitorEvent) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
Update any message producers about our capacity to handle messages
capacityChanged(CapacityMonitorEvent) - Method in interface org.codehaus.activemq.capacity.CapacityMonitorEventListener
called when the capacity of a CapacityMonitor changes
channel - Variable in class org.codehaus.activemq.transport.composite.CompositeTransportChannel
 
checkBrokerSet() - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
 
checkClientIDWasManuallySpecified() - Method in class org.codehaus.activemq.ActiveMQConnection
Ensures that the clientID was manually specified and not auto-generated.
checkClosed() - Method in class org.codehaus.activemq.ActiveMQConnection
simply throws an exception if the Connection is already closed
checkClosed() - Method in class org.codehaus.activemq.ActiveMQMessageConsumer
 
checkClosed() - Method in class org.codehaus.activemq.ActiveMQMessageProducer
 
checkClosed() - Method in class org.codehaus.activemq.ActiveMQSession
 
checkClosed() - Method in class org.codehaus.activemq.store.bdb.BDbMessageStore
 
checkClosed() - Method in class org.codehaus.activemq.store.bdb.BDbPreparedTransactionStore
 
checkClosed() - Method in class org.codehaus.activemq.transport.tcp.TcpBufferedOutputStream
Checks that the stream has not been closed
checkClosedXA() - Method in class org.codehaus.activemq.ActiveMQXASession
 
checkValid() - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
checkpoint() - Method in class org.codehaus.activemq.store.howl.HowlMessageStore
Writes the current RAM cache to the long term, checkpoint store so that the transaction log can be truncated.
checkpoint(ActiveMQMessage) - Method in class org.codehaus.activemq.store.howl.HowlMessageStore
Writes the current RAM image of the transaction log to stable, checkpoint store
checkpoint() - Method in class org.codehaus.activemq.store.journal.JournalMessageStore
 
checksum - Variable in class org.codehaus.activemq.journal.impl.RecordFooter
 
cleanUp() - Method in interface org.codehaus.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.codehaus.activemq.broker.impl.BrokerClientImpl
 
cleanUpClient(BrokerClient) - Method in interface org.codehaus.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.
cleanUpClient(BrokerClient) - Method in class org.codehaus.activemq.service.impl.TransactionManagerImpl
 
cleanup() - Method in class org.codehaus.activemq.ra.ActiveMQManagedConnection
Cleans up all proxy handles attached to this physical connection so that they cannot be used anymore.
cleanup() - Method in class org.codehaus.activemq.ra.JMSConnectionProxy
Called by the ActiveMQManagedConnection to invalidate this proxy.
cleanup() - Method in class org.codehaus.activemq.ra.JMSSessionProxy
Called by the ActiveMQManagedConnection to invalidate this proxy.
clear() - Method in class org.codehaus.activemq.ActiveMQSessionExecutor
 
clear() - Method in interface org.codehaus.activemq.message.util.BoundedPacketQueue
clear the contents from the Queue
clear() - Method in class org.codehaus.activemq.message.util.MemoryBoundedQueue
remove any Packets in the queue
clear() - Method in class org.codehaus.activemq.message.util.SpooledBoundedPacketQueue
clear the queue
clear() - Method in interface org.codehaus.activemq.service.QueueList
Removes all of the elements from this list.
clear() - Method in interface org.codehaus.activemq.service.Subscription
Called when the Subscription is discarded
clear() - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
 
clear() - Method in class org.codehaus.activemq.service.impl.DefaultQueueList
 
clear() - Method in class org.codehaus.activemq.service.impl.MessagePointer
Simply remove the interest in the message
clear() - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
Called when the Subscription is discarded
clearBody() - Method in class org.codehaus.activemq.message.ActiveMQBytesMessage
Clears out the message body.
clearBody() - Method in class org.codehaus.activemq.message.ActiveMQMapMessage
Clears out the message body.
clearBody() - Method in class org.codehaus.activemq.message.ActiveMQMessage
Clears out the message body.
clearBody() - Method in class org.codehaus.activemq.message.ActiveMQObjectMessage
Clears out the message body.
clearBody() - Method in class org.codehaus.activemq.message.ActiveMQStreamMessage
Clears out the message body.
clearBody() - Method in class org.codehaus.activemq.message.ActiveMQTextMessage
Clears out the message body.
clearMessagesInProgress() - Method in class org.codehaus.activemq.ActiveMQConnection
 
clearMessagesInProgress() - Method in class org.codehaus.activemq.ActiveMQMessageConsumer
 
clearMessagesInProgress() - Method in class org.codehaus.activemq.ActiveMQSession
 
clearMessagesInProgress() - Method in class org.codehaus.activemq.ActiveMQSessionExecutor
 
clearProperties() - Method in class org.codehaus.activemq.message.ActiveMQMessage
Clears a message's properties.
clientClosed(ByteArrayServerClient) - Method in class org.codehaus.activemq.transport.ember.EmberTransportServerChannel
 
clientID - Variable in class org.codehaus.activemq.ActiveMQConnection
 
clientID - Variable in class org.codehaus.activemq.ActiveMQConnectionFactory
 
clientIDsEqual(ActiveMQMessage) - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
 
clientId - Variable in class org.codehaus.activemq.message.ConnectionInfo
 
clientVersion - Variable in class org.codehaus.activemq.message.ConnectionInfo
 
clientid - Variable in class org.codehaus.activemq.ra.ActiveMQConnectionRequestInfo
 
clockDaemon - Variable in class org.codehaus.activemq.store.journal.JournalPersistenceAdapter
 
clone() - Method in class org.codehaus.activemq.service.impl.DefaultQueueList
Returns a shallow copy of this DefaultQueueList.
close() - Method in class org.codehaus.activemq.ActiveMQConnection
Closes the connection.
close() - Method in class org.codehaus.activemq.ActiveMQConnectionConsumer
Closes the connection consumer.
close() - Method in class org.codehaus.activemq.ActiveMQMessageConsumer
Closes the message consumer.
close() - Method in class org.codehaus.activemq.ActiveMQMessageProducer
Closes the message producer.
close() - Method in class org.codehaus.activemq.ActiveMQSession
Closes the session.
close() - Method in class org.codehaus.activemq.ActiveMQSessionExecutor
 
close() - Method in class org.codehaus.activemq.ActiveMQXASession
overide Session - which needs to rollback if transacted
close() - Method in class org.codehaus.activemq.broker.impl.BrokerClientImpl
 
close() - Method in class org.codehaus.activemq.jndi.ReadOnlyContext
 
close() - Method in interface org.codehaus.activemq.journal.Journal
Close the Journal.
close() - Method in class org.codehaus.activemq.journal.JournalStatsFilter
 
close() - Method in class org.codehaus.activemq.journal.howl.HowlJournal
 
close() - Method in class org.codehaus.activemq.journal.impl.JournalImpl
 
close() - Method in class org.codehaus.activemq.journal.impl.LogFile
 
close() - Method in class org.codehaus.activemq.journal.impl.LogFileManager
 
close() - Method in class org.codehaus.activemq.journal.impl.Segment
 
close() - Method in class org.codehaus.activemq.message.ReceiptHolder
close this holder
close() - Method in interface org.codehaus.activemq.message.util.BoundedPacketQueue
close and remove this queue
close() - Method in class org.codehaus.activemq.message.util.DataContainer
close the DataContainer and corresponding FileDataBlocks
close() - Method in class org.codehaus.activemq.message.util.FileDataBlock
close and deletes the block
close() - Method in class org.codehaus.activemq.message.util.MemoryBoundedQueue
close and remove this queue from the MemoryBoundedQueueManager
close() - Method in class org.codehaus.activemq.message.util.MemoryBoundedQueueManager
close this queue manager and all associated MemoryBoundedQueues
close() - Method in class org.codehaus.activemq.message.util.SpooledBoundedPacketQueue
close this queue
close() - Method in class org.codehaus.activemq.ra.ActiveMQAsfEndpointWorker.ServerSessionPoolImpl
 
close() - Method in class org.codehaus.activemq.ra.JMSConnectionProxy
Used to let the ActiveMQManagedConnection that this connection handel is not needed by the app.
close() - Method in class org.codehaus.activemq.ra.JMSSessionProxy
 
close() - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
close down this container
close() - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueSubscription
close the subscription
close() - Method in class org.codehaus.activemq.service.boundedvm.TransientSubscription
close the subscription
close() - Method in class org.codehaus.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
close down this container
close() - Method in class org.codehaus.activemq.transport.tcp.TcpBufferedOutputStream
close this stream
close() - Method in class org.codehaus.activemq.util.JmsLogAppenderSupport
 
closeDatabase(Database, JMSException) - Static method in class org.codehaus.activemq.store.bdb.BDbPersistenceAdapter
 
closeTable(BTree, JMSException) - Method in class org.codehaus.activemq.store.jdbm.JdbmMessageStore
 
closed - Variable in class org.codehaus.activemq.ActiveMQMessageProducer
 
closed - Variable in class org.codehaus.activemq.ActiveMQSession
 
closed - Variable in class org.codehaus.activemq.message.ConnectionInfo
 
closed - Variable in class org.codehaus.activemq.ra.JMSSessionProxy
 
closed - Variable in class org.codehaus.activemq.transport.composite.CompositeTransportChannel
 
closing - Variable in class org.codehaus.activemq.ra.ActiveMQAsfEndpointWorker.ServerSessionPoolImpl
 
clusterName - Variable in class org.codehaus.activemq.service.impl.SubscriptionImpl
 
commit() - Method in class org.codehaus.activemq.ActiveMQSession
Commits all messages done in this transaction and releases any locks currently held.
commit() - Method in class org.codehaus.activemq.ActiveMQXASession
 
commit(Xid, boolean) - Method in class org.codehaus.activemq.ActiveMQXASession
 
commit() - Method in class org.codehaus.activemq.ra.JMSSessionProxy
 
commit(boolean) - Method in interface org.codehaus.activemq.service.Transaction
 
commit(boolean) - Method in class org.codehaus.activemq.service.impl.LocalTransactionCommand
 
commit(boolean) - Method in class org.codehaus.activemq.service.impl.XATransactionCommand
 
commitEvent() - Method in interface org.codehaus.activemq.ra.LocalTransactionEventListener
 
commitTransaction(BrokerClient, String) - Method in interface org.codehaus.activemq.broker.Broker
commit a transaction
commitTransaction(BrokerClient, ActiveMQXid, boolean) - Method in interface org.codehaus.activemq.broker.Broker
 
commitTransaction(BrokerClient, String) - Method in interface org.codehaus.activemq.broker.BrokerConnector
Commit a transaction
commitTransaction(BrokerClient, ActiveMQXid, boolean) - Method in interface org.codehaus.activemq.broker.BrokerConnector
Commit an XA transaction.
commitTransaction(BrokerClient, String) - Method in interface org.codehaus.activemq.broker.BrokerContainer
Commit a transaction
commitTransaction(BrokerClient, ActiveMQXid, boolean) - Method in interface org.codehaus.activemq.broker.BrokerContainer
Commit an XA transaction.
commitTransaction(BrokerClient, String) - Method in class org.codehaus.activemq.broker.impl.BrokerConnectorImpl
Commit a transaction
commitTransaction(BrokerClient, ActiveMQXid, boolean) - Method in class org.codehaus.activemq.broker.impl.BrokerConnectorImpl
Commit an XA transaction.
commitTransaction(BrokerClient, String) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
Commit a transaction
commitTransaction(BrokerClient, ActiveMQXid, boolean) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
Commit an XA transaction.
commitTransaction(BrokerClient, String) - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
commitTransaction(BrokerClient, ActiveMQXid, boolean) - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
Commit an XA Transaction.
commitTransaction(BrokerClient, String) - Method in interface org.codehaus.activemq.service.MessageContainerManager
A hook when the transaction is about to be commited; so apply all outstanding commands to the Journal if using a Journal (transaction log)
commitTransaction(BrokerClient, String) - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageManager
A hook when the transaction is about to be commited; so apply all outstanding commands to the Journal if using a Journal (transaction log)
commitTransaction(BrokerClient, String) - Method in class org.codehaus.activemq.service.boundedvm.TransientTopicBoundedMessageManager
A hook when the transaction is about to be commited; so apply all outstanding commands to the Journal if using a Journal (transaction log)
commitTransaction(BrokerClient, String) - Method in class org.codehaus.activemq.service.impl.DurableQueueMessageContainerManager
 
commitTransaction(BrokerClient, String) - Method in class org.codehaus.activemq.service.impl.DurableTopicMessageContainerManager
 
commitTransaction(BrokerClient, String) - Method in class org.codehaus.activemq.service.impl.ProxyMessageContainerManager
 
commitTransaction() - Method in interface org.codehaus.activemq.store.PersistenceAdapter
Commit a persistence transaction
commitTransaction() - Method in class org.codehaus.activemq.store.bdb.BDbPersistenceAdapter
 
commitTransaction(DbTxn) - Static method in class org.codehaus.activemq.store.bdbn.BDbHelper
Commit a transaction, throwing a JMSException if a failure occurs to avoid TRA rolling back
commitTransaction() - Method in class org.codehaus.activemq.store.bdbn.BDbPersistenceAdapter
 
commitTransaction() - Method in class org.codehaus.activemq.store.cache.CachePersistenceAdapter
 
commitTransaction() - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
commitTransaction() - Method in class org.codehaus.activemq.store.jdbc.JDBCPersistenceAdapter
 
commitTransaction() - Method in class org.codehaus.activemq.store.jdbm.JdbmPersistenceAdapter
 
commitTransaction() - Method in class org.codehaus.activemq.store.journal.JournalPersistenceAdapter
 
commitTransaction() - Method in class org.codehaus.activemq.store.vm.VMPersistenceAdapter
 
compare(Comparable, Comparable) - Method in class org.codehaus.activemq.filter.ComparisonExpression
 
compare(Object, Object) - Method in class org.codehaus.activemq.util.DefaultComparator
 
compare(String, String) - Static method in class org.codehaus.activemq.util.IdGenerator
Does a proper compare on the ids
compareTo(Object) - Method in class org.codehaus.activemq.journal.howl.LongRecordLocation
 
compareTo(Object) - Method in class org.codehaus.activemq.journal.impl.RecordLocationImpl
 
compareTo(Object) - Method in class org.codehaus.activemq.message.ActiveMQDestination
 
compareTo(ActiveMQDestination) - Method in class org.codehaus.activemq.message.ActiveMQDestination
Lets sort by name first then lets sort topics greater than queues
compareTo(Object) - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
compareTo(ActiveMQMessage) - Method in class org.codehaus.activemq.message.ActiveMQMessage
Sorted by destination and then messageId
compareTo(Object) - Method in class org.codehaus.activemq.message.ActiveMQXid
 
compareTo(byte[], byte[]) - Method in class org.codehaus.activemq.message.ActiveMQXid
 
compareTo(Object) - Method in class org.codehaus.activemq.service.MessageIdentity
 
comparisonExpression() - Method in class org.codehaus.activemq.selector.SelectorParser
 
composeName(Name, Name) - Method in class org.codehaus.activemq.jndi.ReadOnlyContext
 
composeName(String, String) - Method in class org.codehaus.activemq.jndi.ReadOnlyContext
 
configureChannel() - Method in class org.codehaus.activemq.transport.composite.CompositeTransportChannel
 
configureChannel() - Method in class org.codehaus.activemq.transport.reliable.ReliableTransportChannel
 
configureConnection(HttpURLConnection) - Method in class org.codehaus.activemq.transport.http.HttpTransportChannel
 
configureMethod(HttpMethod) - Method in class org.codehaus.activemq.transport.http.HttpClientTransportChannel
 
connect() - Method in class org.codehaus.activemq.transport.multicast.MulticastTransportChannel
 
connect() - Method in class org.codehaus.activemq.transport.udp.UdpTransportChannel
 
connect(BrokerConnector) - Method in class org.codehaus.activemq.transport.vm.VmTransportChannel
Connects the client side transport channel with the broker
connection - Variable in class org.codehaus.activemq.ActiveMQSession
 
connectionClosed(ConnectionEvent) - Method in class org.codehaus.activemq.ra.DefaultConnectionManager
 
connectionClosed(ConnectionEvent) - Method in class org.codehaus.activemq.ra.SimpleConnectionManager
 
connectionErrorOccurred(ConnectionEvent) - Method in class org.codehaus.activemq.ra.DefaultConnectionManager
 
connectionErrorOccurred(ConnectionEvent) - Method in class org.codehaus.activemq.ra.SimpleConnectionManager
 
connectionFactoryAttribute - Static variable in class org.codehaus.activemq.web.WebClient
 
consume(Packet) - Method in class org.codehaus.activemq.ActiveMQConnection
Implementation of the PacketListener interface - consume a packet
consume(Packet) - Method in class org.codehaus.activemq.broker.impl.BrokerClientImpl
Consume a Packet from the underlying TransportChannel for processing
consume(Packet) - Method in interface org.codehaus.activemq.message.PacketListener
Consume a Packet
consume(Packet) - Method in class org.codehaus.activemq.transport.reliable.ReliableTransportChannel
consume a packet from the enbedded channel
consumeConnectionInfo(ConnectionInfo) - Method in class org.codehaus.activemq.broker.impl.BrokerClientImpl
register with the Broker
consumeConsumerInfo(ConsumerInfo) - Method in class org.codehaus.activemq.broker.impl.BrokerClientImpl
Register/deregister MessageConsumer with the Broker
consumer - Variable in class org.codehaus.activemq.ra.ActiveMQAsfEndpointWorker
 
consumer - Variable in class org.codehaus.activemq.web.WebClient.SessionConsumerPair
 
consumerId - Variable in class org.codehaus.activemq.ActiveMQMessageConsumer
 
consumerIdGenerator - Variable in class org.codehaus.activemq.ActiveMQConnection
 
consumerInfo - Variable in class org.codehaus.activemq.service.boundedvm.TransientSubscription
 
consumerName - Variable in class org.codehaus.activemq.ActiveMQMessageConsumer
 
consumerNumber - Variable in class org.codehaus.activemq.ActiveMQMessageConsumer
 
consumers - Variable in class org.codehaus.activemq.ActiveMQSession
 
containerNameDataType - Variable in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
containerShutdown() - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
Causes a clean shutdown of the container when the VM is being shut down
contains(Object) - Method in interface org.codehaus.activemq.service.QueueList
Returns true if this list contains the specified element.
contains(Object) - Method in class org.codehaus.activemq.service.impl.DefaultQueueList
 
contains(Object) - Method in class org.codehaus.activemq.service.impl.QueueListSupport
 
containsMessage(MessageIdentity) - Method in interface org.codehaus.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.
containsMessage(MessageIdentity) - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
 
containsMessage(MessageIdentity) - Method in class org.codehaus.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
 
containsMessage(MessageIdentity) - Method in class org.codehaus.activemq.service.impl.DurableQueueMessageContainer
 
containsMessage(MessageIdentity) - Method in class org.codehaus.activemq.service.impl.DurableTopicMessageContainer
 
convertBodyToBytes() - Method in class org.codehaus.activemq.message.ActiveMQMessage
Convert the message body to data
copy(Mark) - Method in class org.codehaus.activemq.journal.impl.Mark
 
copy() - Method in class org.codehaus.activemq.message.DefaultWireFormat
 
copy() - Method in class org.codehaus.activemq.message.WireFormat
Creates a new copy of this wire format so it can be used in another thread/context
copy() - Method in class org.codehaus.activemq.ra.ActiveMQConnectionRequestInfo
 
copy() - Method in class org.codehaus.activemq.transport.jabber.JabberWireFormat
 
copy() - Method in class org.codehaus.activemq.transport.xstream.XStreamWireFormat
 
counter - Variable in class org.codehaus.activemq.store.bdb.StubSecondaryKeyGenerator
 
create(WireFormat, URI) - Method in class org.codehaus.activemq.transport.DiscoveryTransportChannelFactorySupport
 
create(WireFormat, URI) - Method in interface org.codehaus.activemq.transport.TransportChannelFactory
Create a Channel to a remote Node - e.g.
create(WireFormat, URI, URI) - Method in interface org.codehaus.activemq.transport.TransportChannelFactory
Create a Channel to a remote Node - e.g.
create(WireFormat, URI) - Static method in class org.codehaus.activemq.transport.TransportChannelProvider
Create a Channel to a remote Node - e.g.
create(WireFormat, URI, URI) - Static method in class org.codehaus.activemq.transport.TransportChannelProvider
Create a Channel to a remote Node - e.g.
create(WireFormat, URI) - Method in interface org.codehaus.activemq.transport.TransportServerChannelFactory
Bind a ServerChannel to an address
create(WireFormat, URI) - Static method in class org.codehaus.activemq.transport.TransportServerChannelProvider
Create a Channel used for the Broker to listen to remove connections
create(WireFormat, URI) - Method in class org.codehaus.activemq.transport.composite.CompositeTransportChannelFactory
 
create(WireFormat, URI, URI) - Method in class org.codehaus.activemq.transport.composite.CompositeTransportChannelFactory
 
create(WireFormat, URI) - Method in class org.codehaus.activemq.transport.ember.EmberTransportChannelFactory
Create a Channel to a remote Node - e.g.
create(WireFormat, URI, URI) - Method in class org.codehaus.activemq.transport.ember.EmberTransportChannelFactory
Create a Channel to a remote Node - e.g.
create(WireFormat, URI) - Method in class org.codehaus.activemq.transport.ember.EmberTransportServerChannelFactory
Bind a ServerChannel to an address
create(WireFormat, URI) - Method in class org.codehaus.activemq.transport.gnet.GTransportChannelFactory
Create a Channel to a remote Node - e.g.
create(WireFormat, URI, URI) - Method in class org.codehaus.activemq.transport.gnet.GTransportChannelFactory
Create a Channel to a remote Node - e.g.
create(WireFormat, URI) - Method in class org.codehaus.activemq.transport.gnet.GTransportServerChannelFactory
Bind a ServerChannel to an address
create(WireFormat, URI) - Method in class org.codehaus.activemq.transport.http.HttpTransportChannelFactory
 
create(WireFormat, URI, URI) - Method in class org.codehaus.activemq.transport.http.HttpTransportChannelFactory
 
create(WireFormat, URI) - Method in class org.codehaus.activemq.transport.http.HttpTransportConnectorFactory
 
create(WireFormat, URI) - Method in class org.codehaus.activemq.transport.jgroups.JGroupsTransportChannelFactory
 
create(WireFormat, URI, URI) - Method in class org.codehaus.activemq.transport.jgroups.JGroupsTransportChannelFactory
 
create(WireFormat, URI) - Method in class org.codehaus.activemq.transport.jgroups.JGroupsTransportServerChannelFactory
 
create(WireFormat, URI) - Method in class org.codehaus.activemq.transport.jrms.JRMSTransportChannelFactory
Create a Channel to a remote Node - e.g.
create(WireFormat, URI, URI) - Method in class org.codehaus.activemq.transport.jrms.JRMSTransportChannelFactory
Create a Channel to a remote Node - e.g.
create(WireFormat, URI) - Method in class org.codehaus.activemq.transport.jrms.JRMSTransportServerChannelFactory
Bind a ServerChannel to an address
create(WireFormat, URI) - Method in class org.codehaus.activemq.transport.jxta.JxtaTransportChannelFactory
Create a Channel to a remote Node - e.g.
create(WireFormat, URI, URI) - Method in class org.codehaus.activemq.transport.jxta.JxtaTransportChannelFactory
Create a Channel to a remote Node - e.g.
create(WireFormat, URI) - Method in class org.codehaus.activemq.transport.jxta.JxtaTransportServerChannelFactory
Bind a ServerChannel to an address
create(WireFormat, URI) - Method in class org.codehaus.activemq.transport.multicast.MulticastTransportChannelFactory
Create a Channel to a remote Node - e.g.
create(WireFormat, URI, URI) - Method in class org.codehaus.activemq.transport.multicast.MulticastTransportChannelFactory
Create a Channel to a remote Node - e.g.
create(WireFormat, URI) - Method in class org.codehaus.activemq.transport.multicast.MulticastTransportServerChannelFactory
Bind a ServerChannel to an address
create(WireFormat, URI) - Method in class org.codehaus.activemq.transport.reliable.ReliableTransportChannelFactory
Create a TransportChannel
create(WireFormat, URI) - Method in class org.codehaus.activemq.transport.tcp.SfTransportChannelFactory
Create a Channel to a remote Node - e.g.
create(WireFormat, URI, URI) - Method in class org.codehaus.activemq.transport.tcp.SfTransportChannelFactory
Create a Channel to a remote Node - e.g.
create(WireFormat, URI) - Method in class org.codehaus.activemq.transport.tcp.SfTransportServerChannelFactory
Bind a ServerChannel to an address
create(WireFormat, URI) - Method in class org.codehaus.activemq.transport.tcp.TcpTransportChannelFactory
Create a Channel to a remote Node - e.g.
create(WireFormat, URI, URI) - Method in class org.codehaus.activemq.transport.tcp.TcpTransportChannelFactory
Create a Channel to a remote Node - e.g.
create(WireFormat, URI) - Method in class org.codehaus.activemq.transport.tcp.TcpTransportServerChannelFactory
Bind a ServerChannel to an address
create(WireFormat, URI) - Method in class org.codehaus.activemq.transport.udp.UdpTransportChannelFactory
Create a Channel to a remote Node - e.g.
create(WireFormat, URI, URI) - Method in class org.codehaus.activemq.transport.udp.UdpTransportChannelFactory
Create a Channel to a remote Node - e.g.
create(WireFormat, URI) - Method in class org.codehaus.activemq.transport.udp.UdpTransportServerChannelFactory
Bind a ServerChannel to an address
create(WireFormat, URI) - Method in class org.codehaus.activemq.transport.vm.VmTransportChannelFactory
Create a Channel to a remote Node - e.g.
create(WireFormat, URI, URI) - Method in class org.codehaus.activemq.transport.vm.VmTransportChannelFactory
Create a Channel to a remote Node - e.g.
create(WireFormat, URI) - Method in class org.codehaus.activemq.transport.vm.VmTransportServerChannelFactory
Bind a ServerChannel to an address
create(WireFormat, URI) - Method in class org.codehaus.activemq.transport.zeroconf.ZeroconfTransportConnectorFactory
 
createAND(BooleanExpression, BooleanExpression) - Static method in class org.codehaus.activemq.filter.LogicExpression
 
createActiveMQXAConnection(String, String) - Method in class org.codehaus.activemq.ActiveMQXAConnectionFactory
 
createActiveMQXASession() - Method in class org.codehaus.activemq.ActiveMQXAConnection
 
createBetween(Expression, Expression, Expression) - Static method in class org.codehaus.activemq.filter.ComparisonExpression
 
createBrokerClient(String) - Method in class org.codehaus.activemq.service.impl.PacketTransactionTask
 
createBrokerConnector(String) - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
 
createBrokerConnector() - Method in class org.codehaus.activemq.gbean.ActiveMQConnectorGBean
 
createBrokerContainer(String, BrokerContext) - Method in interface org.codehaus.activemq.broker.BrokerContainerFactory
Creates a broker container with the given name
createBrokerContainer(String, BrokerContext) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerFactoryImpl
 
createBrokerContainer(String, BrokerContext) - Method in class org.codehaus.activemq.spring.SpringBrokerContainerFactory
 
createBrokerContainerFactory() - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
 
createBrokerContainerFactory(String) - Static method in class org.codehaus.activemq.XmlConfigHelper
Creates an instance of the broker factory which uses the Spring XML configuration file mechanism.
createBrowser(Queue) - Method in class org.codehaus.activemq.ActiveMQSession
Creates a QueueBrowser object to peek at the messages on the specified queue.
createBrowser(Queue, String) - Method in class org.codehaus.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.codehaus.activemq.ra.JMSSessionProxy
 
createBrowser(Queue, String) - Method in class org.codehaus.activemq.ra.JMSSessionProxy
 
createBytesMessage() - Method in class org.codehaus.activemq.ActiveMQSession
Creates a BytesMessage object.
createBytesMessage() - Method in class org.codehaus.activemq.ra.JMSSessionProxy
 
createChannel(URI) - Method in class org.codehaus.activemq.transport.jgroups.JGroupsTransportChannelFactory
 
createChannel(int) - Method in class org.codehaus.activemq.transport.vm.VmTransportChannel
 
createChildNode() - Method in class org.codehaus.activemq.filter.DestinationMapNode
Factory method to create a child node
createClient(EmberServiceController, URI, String) - Method in class org.codehaus.activemq.transport.ember.EmberTransportChannelFactory
 
createConfiguration() - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
createConnection() - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
Create a JMS Connection
createConnection(String, String) - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
 
createConnection() - Method in class org.codehaus.activemq.ActiveMQXAConnectionFactory
 
createConnection(String, String) - Method in class org.codehaus.activemq.ActiveMQXAConnectionFactory
 
createConnection() - Method in class org.codehaus.activemq.ra.ActiveMQConnectionFactory
 
createConnection(String, String) - Method in class org.codehaus.activemq.ra.ActiveMQConnectionFactory
 
createConnection() - Method in class org.codehaus.activemq.util.JmsLogAppender
 
createConnection() - Method in class org.codehaus.activemq.util.JmsLogAppenderSupport
 
createConnection() - Method in class org.codehaus.activemq.util.JndiJmsLogAppender
 
createConnectionConsumer(Destination, String, ServerSessionPool, int) - Method in class org.codehaus.activemq.ActiveMQConnection
Creates a connection consumer for this connection (optional operation).
createConnectionConsumer(Topic, String, ServerSessionPool, int) - Method in class org.codehaus.activemq.ActiveMQConnection
Creates a connection consumer for this connection (optional operation).
createConnectionConsumer(Queue, String, ServerSessionPool, int) - Method in class org.codehaus.activemq.ActiveMQConnection
Creates a connection consumer for this connection (optional operation).
createConnectionConsumer(Queue, String, ServerSessionPool, int) - Method in class org.codehaus.activemq.ra.JMSConnectionProxy
 
createConnectionConsumer(Topic, String, ServerSessionPool, int) - Method in class org.codehaus.activemq.ra.JMSConnectionProxy
 
createConnectionConsumer(Destination, String, ServerSessionPool, int) - Method in class org.codehaus.activemq.ra.JMSConnectionProxy
 
createConnectionFactory(Hashtable) - Method in class org.codehaus.activemq.jndi.ActiveMQInitialContextFactory
Factory method to create a new connection factory from the given environment
createConnectionFactory(ConnectionManager) - Method in class org.codehaus.activemq.ra.ActiveMQManagedConnectionFactory
 
createConnectionFactory() - Method in class org.codehaus.activemq.ra.ActiveMQManagedConnectionFactory
This is used when not running in an app server.
createConsumer(Destination) - Method in class org.codehaus.activemq.ActiveMQSession
Creates a MessageConsumer for the specified destination.
createConsumer(Destination, String) - Method in class org.codehaus.activemq.ActiveMQSession
Creates a MessageConsumer for the specified destination, using a message selector.
createConsumer(Destination, String, boolean) - Method in class org.codehaus.activemq.ActiveMQSession
Creates MessageConsumer for the specified destination, using a message selector.
createConsumer(Destination) - Method in class org.codehaus.activemq.ra.JMSSessionProxy
 
createConsumer(Destination, String) - Method in class org.codehaus.activemq.ra.JMSSessionProxy
 
createConsumer(Destination, String, boolean) - Method in class org.codehaus.activemq.ra.JMSSessionProxy
 
createConsumerInfo(ActiveMQMessageConsumer) - Method in class org.codehaus.activemq.ActiveMQSession
 
createContainer() - Method in class org.codehaus.activemq.gbean.ActiveMQContainerGBean
 
createContainer(String) - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageManager
 
createContainer(String) - Method in class org.codehaus.activemq.service.impl.DurableQueueMessageContainerManager
 
createContainer(String) - Method in class org.codehaus.activemq.service.impl.DurableTopicMessageContainerManager
 
createContainer(String) - Method in class org.codehaus.activemq.service.impl.MessageContainerManagerSupport
Factory method to create a new MessageContainer
createContainerManagers() - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
Factory method to create the default container managers
createDatabase(String) - Method in class org.codehaus.activemq.store.bdb.BDbPersistenceAdapter
 
createDatabase(String) - Method in class org.codehaus.activemq.store.bdbn.BDbPersistenceAdapter
 
createDatabase(String) - Method in class org.codehaus.activemq.store.jdbm.JdbmPersistenceAdapter
 
createDatabaseConfig() - Static method in class org.codehaus.activemq.store.bdb.BDbHelper
 
createDatagramPacket() - Method in class org.codehaus.activemq.transport.jrms.JRMSTransportChannel
 
createDatagramPacket(Packet) - Method in class org.codehaus.activemq.transport.jrms.JRMSTransportChannel
 
createDatagramPacket() - Method in class org.codehaus.activemq.transport.udp.UdpTransportChannel
 
createDatagramPacket(Packet) - Method in class org.codehaus.activemq.transport.udp.UdpTransportChannel
 
createDestination(String) - Method in class org.codehaus.activemq.message.ActiveMQDestination
Factory method to create a child destination if this destination is a composite
createDestination(String) - Method in class org.codehaus.activemq.message.ActiveMQQueue
 
createDestination(String) - Method in class org.codehaus.activemq.message.ActiveMQTopic
 
createDestination(String) - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageManager
 
createDestination(String) - Method in class org.codehaus.activemq.service.impl.DurableQueueMessageContainerManager
 
createDestination(String) - Method in class org.codehaus.activemq.service.impl.DurableTopicMessageContainerManager
 
createDestination(String) - Method in class org.codehaus.activemq.service.impl.MessageContainerManagerSupport
Factory method to create a new Destination
createDestinationStats() - Method in class org.codehaus.activemq.message.ActiveMQDestination
Factory method to create a statistics counter object
createDestinationStats() - Method in class org.codehaus.activemq.message.ActiveMQQueue
 
createDestinationStats() - Method in class org.codehaus.activemq.message.ActiveMQTopic
 
createDiscoveryAgent(URI) - Method in class org.codehaus.activemq.transport.DiscoveryTransportChannelFactorySupport
 
createDiscoveryAgent(URI) - Method in class org.codehaus.activemq.transport.zeroconf.ZeroconfTransportChannelFactory
 
createDivide(Expression, Expression) - Static method in class org.codehaus.activemq.filter.ArithmeticExpression
 
createDurableConnectionConsumer(Topic, String, String, ServerSessionPool, int) - Method in class org.codehaus.activemq.ActiveMQConnection
Create a durable connection consumer for this connection (optional operation).
createDurableConnectionConsumer(Topic, String, String, ServerSessionPool, int) - Method in class org.codehaus.activemq.ra.JMSConnectionProxy
 
createDurableSubscriber(Topic, String) - Method in class org.codehaus.activemq.ActiveMQSession
Creates a durable subscriber to the specified topic.
createDurableSubscriber(Topic, String, String, boolean) - Method in class org.codehaus.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.codehaus.activemq.ra.JMSSessionProxy
 
createDurableSubscriber(Topic, String, String, boolean) - Method in class org.codehaus.activemq.ra.JMSSessionProxy
 
createEntityResolver() - Method in class org.codehaus.activemq.spring.ActiveMQBeanDefinitionReader
 
createEnvironment(File) - Static method in class org.codehaus.activemq.store.bdb.BDbHelper
 
createEnvironment(File, boolean) - Static method in class org.codehaus.activemq.store.bdbn.BDbHelper
 
createEqual(Expression, Expression) - Static method in class org.codehaus.activemq.filter.ComparisonExpression
 
createFilter(Destination, String) - Method in interface org.codehaus.activemq.filter.FilterFactory
 
createFilter(Destination, String) - Method in class org.codehaus.activemq.filter.FilterFactoryImpl
 
createFilter(ConsumerInfo) - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageManager
Create filter for a Consumer
createFilter(ConsumerInfo) - Method in class org.codehaus.activemq.service.boundedvm.TransientTopicBoundedMessageManager
Create filter for a Consumer
createFilter(ConsumerInfo) - Method in class org.codehaus.activemq.service.impl.DurableQueueMessageContainerManager
Create filter for a Consumer
createFilter(ConsumerInfo) - Method in class org.codehaus.activemq.service.impl.DurableTopicMessageContainerManager
Create filter for a Consumer
createFloat(String) - Static method in class org.codehaus.activemq.filter.ConstantExpression
 
createGreaterThan(Expression, Expression) - Static method in class org.codehaus.activemq.filter.ComparisonExpression
 
createGreaterThanEqual(Expression, Expression) - Static method in class org.codehaus.activemq.filter.ComparisonExpression
 
createHttpClient() - Method in class org.codehaus.activemq.transport.http.HttpClientTransportChannel
 
createInFilter(Expression, List) - Static method in class org.codehaus.activemq.filter.ComparisonExpression
 
createInitialContext() - Method in class org.codehaus.activemq.util.JndiJmsLogAppender
 
createInstantiateAdapterException(Class, Throwable) - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
createInteger(String) - Static method in class org.codehaus.activemq.filter.ConstantExpression
 
createIsNotNull(Expression) - Static method in class org.codehaus.activemq.filter.ComparisonExpression
 
createIsNull(Expression) - Static method in class org.codehaus.activemq.filter.ComparisonExpression
 
createJMSException(String, Exception) - Method in class org.codehaus.activemq.transport.ember.EmberSupport
Factory method to create a JMSException which is linked to the base exception
createJMSException(String, Exception) - Method in class org.codehaus.activemq.transport.ember.EmberTransportChannel
Factory method to create a JMSException which is linked to the base exception
createJMSexception(String, Exception) - Static method in class org.codehaus.activemq.transport.TransportChannelProvider
 
createJMSexception(String, Exception) - Static method in class org.codehaus.activemq.transport.TransportServerChannelProvider
 
createJmDNS() - Method in class org.codehaus.activemq.transport.zeroconf.ZeroconfDiscoveryAgent
 
createKey(QueueListSupport.Header) - Method in class org.codehaus.activemq.service.impl.QueueListSupport
 
createKey(String) - Method in class org.codehaus.activemq.store.bdb.BDbMessageStore
 
createKey(String) - Method in class org.codehaus.activemq.store.bdbn.BDbMessageStore
 
createLessThan(Expression, Expression) - Static method in class org.codehaus.activemq.filter.ComparisonExpression
 
createLessThanEqual(Expression, Expression) - Static method in class org.codehaus.activemq.filter.ComparisonExpression
 
createLike(Expression, String, String) - Static method in class org.codehaus.activemq.filter.ComparisonExpression
 
createLocalAddress() - Method in class org.codehaus.activemq.transport.zeroconf.ZeroconfDiscoveryAgent
 
createLocalDiscoveryDetails() - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
 
createLocalTransaction(BrokerClient, String) - Method in interface org.codehaus.activemq.service.TransactionManager
 
createLocalTransaction(BrokerClient, String) - Method in class org.codehaus.activemq.service.impl.TransactionManagerImpl
 
createManagedConnection(Subject, ConnectionRequestInfo) - Method in class org.codehaus.activemq.ra.ActiveMQManagedConnectionFactory
 
createMapMessage() - Method in class org.codehaus.activemq.ActiveMQSession
Creates a MapMessage object.
createMapMessage() - Method in class org.codehaus.activemq.ra.JMSSessionProxy
 
createMessage() - Method in class org.codehaus.activemq.ActiveMQSession
Creates a Message object.
createMessage() - Method in class org.codehaus.activemq.ra.JMSSessionProxy
 
createMessage(LoggingEvent) - Method in class org.codehaus.activemq.util.JmsLogAppenderSupport
 
createMessageCache(String) - Method in class org.codehaus.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.codehaus.activemq.store.cache.SimpleCachePersistenceAdapter
 
createMinus(Expression, Expression) - Static method in class org.codehaus.activemq.filter.ArithmeticExpression
 
createMod(Expression, Expression) - Static method in class org.codehaus.activemq.filter.ArithmeticExpression
 
createMulticastClientID() - Method in class org.codehaus.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.codehaus.activemq.filter.ArithmeticExpression
 
createNOT(BooleanExpression) - Static method in class org.codehaus.activemq.filter.UnaryExpression
 
createNegate(Expression) - Static method in class org.codehaus.activemq.filter.UnaryExpression
 
createNetworkChannel(String, Map) - Method in class org.codehaus.activemq.transport.DiscoveryNetworkConnector
 
createNioService(EmberServiceController) - Method in class org.codehaus.activemq.transport.ember.EmberTransportChannelFactory
Factory method to create a new ObjectClientService
createNode() - Method in class org.codehaus.activemq.service.impl.QueueListSupport
 
createNotBetween(Expression, Expression, Expression) - Static method in class org.codehaus.activemq.filter.ComparisonExpression
 
createNotEqual(Expression, Expression) - Static method in class org.codehaus.activemq.filter.ComparisonExpression
 
createNotInFilter(Expression, List) - Static method in class org.codehaus.activemq.filter.ComparisonExpression
 
createNotLike(Expression, String, String) - Static method in class org.codehaus.activemq.filter.ComparisonExpression
 
createOR(BooleanExpression, BooleanExpression) - Static method in class org.codehaus.activemq.filter.LogicExpression
 
createObjectMessage() - Method in class org.codehaus.activemq.ActiveMQSession
Creates an ObjectMessage object.
createObjectMessage(Serializable) - Method in class org.codehaus.activemq.ActiveMQSession
Creates an initialized ObjectMessage object.
createObjectMessage() - Method in class org.codehaus.activemq.ra.JMSSessionProxy
 
createObjectMessage(Serializable) - Method in class org.codehaus.activemq.ra.JMSSessionProxy
 
createPacket() - Method in class org.codehaus.activemq.message.ActiveMQBytesMessageReader
 
createPacket() - Method in class org.codehaus.activemq.message.ActiveMQMapMessageReader
 
createPacket() - Method in class org.codehaus.activemq.message.ActiveMQMessageReader
 
createPacket() - Method in class org.codehaus.activemq.message.ActiveMQObjectMessageReader
 
createPacket() - Method in class org.codehaus.activemq.message.ActiveMQStreamMessageReader
 
createPacket() - Method in class org.codehaus.activemq.message.ActiveMQTextMessageReader
 
createPacket() - Method in class org.codehaus.activemq.message.BrokerInfoReader
 
createPacket() - Method in class org.codehaus.activemq.message.CapacityInfoReader
 
createPacket() - Method in class org.codehaus.activemq.message.CapacityInfoRequestReader
 
createPacket() - Method in class org.codehaus.activemq.message.ConnectionInfoReader
 
createPacket() - Method in class org.codehaus.activemq.message.ConsumerInfoReader
 
createPacket() - Method in class org.codehaus.activemq.message.DurableUnsubscribeReader
 
createPacket() - Method in class org.codehaus.activemq.message.IntResponseReceiptReader
 
createPacket() - Method in class org.codehaus.activemq.message.MessageAckReader
 
createPacket() - Method in interface org.codehaus.activemq.message.PacketReader
 
createPacket() - Method in class org.codehaus.activemq.message.ProducerInfoReader
 
createPacket() - Method in class org.codehaus.activemq.message.ReceiptReader
 
createPacket() - Method in class org.codehaus.activemq.message.ResponseReceiptReader
 
createPacket() - Method in class org.codehaus.activemq.message.SessionInfoReader
 
createPacket() - Method in class org.codehaus.activemq.message.TransactionInfoReader
 
createPacket() - Method in class org.codehaus.activemq.message.WireFormatInfoReader
 
createPacket() - Method in class org.codehaus.activemq.message.XATransactionInfoReader
 
createPacketListenerSender() - Method in class org.codehaus.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.codehaus.activemq.broker.impl.DefaultBroker
Factory method to create a default persistence adapter
createPlus(Expression, Expression) - Static method in class org.codehaus.activemq.filter.ArithmeticExpression
 
createPreparedTransactionStore() - Method in interface org.codehaus.activemq.store.PersistenceAdapter
Factory method to create a new persistent prepared transaction store for XA recovery
createPreparedTransactionStore() - Method in class org.codehaus.activemq.store.bdb.BDbPersistenceAdapter
 
createPreparedTransactionStore() - Method in class org.codehaus.activemq.store.bdbn.BDbPersistenceAdapter
 
createPreparedTransactionStore() - Method in class org.codehaus.activemq.store.cache.CachePersistenceAdapter
 
createPreparedTransactionStore() - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
createPreparedTransactionStore() - Method in class org.codehaus.activemq.store.jdbc.JDBCPersistenceAdapter
 
createPreparedTransactionStore() - Method in class org.codehaus.activemq.store.jdbm.JdbmPersistenceAdapter
 
createPreparedTransactionStore() - Method in class org.codehaus.activemq.store.journal.JournalPersistenceAdapter
 
createPreparedTransactionStore() - Method in class org.codehaus.activemq.store.vm.VMPersistenceAdapter
 
createProducer(Destination) - Method in class org.codehaus.activemq.ActiveMQSession
Creates a MessageProducer to send messages to the specified destination.
createProducer(Destination) - Method in class org.codehaus.activemq.ra.JMSSessionProxy
 
createProducer() - Method in class org.codehaus.activemq.util.JmsLogAppenderSupport
 
createProducerInfo(ActiveMQMessageProducer) - Method in class org.codehaus.activemq.ActiveMQSession
 
createProxy(Class, Object, Executor) - Static method in class org.codehaus.activemq.util.AsyncProxy
 
createPublisher(Topic) - Method in class org.codehaus.activemq.ActiveMQSession
Creates a publisher for the specified topic.
createPublisher(Topic) - Method in class org.codehaus.activemq.ra.JMSSessionProxy
 
createQueue(String) - Method in class org.codehaus.activemq.ActiveMQSession
Creates a queue identity given a Queue name.
createQueue(String) - Method in class org.codehaus.activemq.jndi.ActiveMQInitialContextFactory
Factory method to create new Queue instances
createQueue(String) - Method in class org.codehaus.activemq.ra.JMSSessionProxy
 
createQueueConnection() - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
Create a JMS QueueConnection
createQueueConnection(String, String) - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
 
createQueueConnection() - Method in class org.codehaus.activemq.ActiveMQXAConnectionFactory
 
createQueueConnection(String, String) - Method in class org.codehaus.activemq.ActiveMQXAConnectionFactory
 
createQueueConnection() - Method in class org.codehaus.activemq.ra.ActiveMQConnectionFactory
 
createQueueConnection(String, String) - Method in class org.codehaus.activemq.ra.ActiveMQConnectionFactory
 
createQueueMessageContainer(String) - Method in class org.codehaus.activemq.service.impl.PersistenceAdapterSupport
 
createQueueMessageContainer(String) - Method in interface org.codehaus.activemq.store.PersistenceAdapter
Factory method to create a new durable queue based message contaienr
createQueueMessageStore(String) - Method in interface org.codehaus.activemq.store.PersistenceAdapter
Factory method to create a new queue message store with the given destination name
createQueueMessageStore(String) - Method in class org.codehaus.activemq.store.bdb.BDbPersistenceAdapter
 
createQueueMessageStore(String) - Method in class org.codehaus.activemq.store.bdbn.BDbPersistenceAdapter
 
createQueueMessageStore(String) - Method in class org.codehaus.activemq.store.cache.CachePersistenceAdapter
 
createQueueMessageStore(String) - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
createQueueMessageStore(String) - Method in class org.codehaus.activemq.store.jdbc.JDBCPersistenceAdapter
 
createQueueMessageStore(String) - Method in class org.codehaus.activemq.store.jdbm.JdbmPersistenceAdapter
 
createQueueMessageStore(String) - Method in class org.codehaus.activemq.store.journal.JournalPersistenceAdapter
 
createQueueMessageStore(String) - Method in class org.codehaus.activemq.store.vm.VMPersistenceAdapter
 
createQueueSession(boolean, int) - Method in class org.codehaus.activemq.ActiveMQConnection
Creates a QueueSession object.
createQueueSession(boolean, int) - Method in class org.codehaus.activemq.ActiveMQXAConnection
 
createQueueSession(boolean, int) - Method in class org.codehaus.activemq.ra.JMSConnectionProxy
 
createQueues(Map, Hashtable) - Method in class org.codehaus.activemq.jndi.ActiveMQInitialContextFactory
 
createReader(String) - Method in class org.codehaus.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.codehaus.activemq.ActiveMQSession
Creates a QueueReceiver object to receive messages from the specified queue.
createReceiver(Queue, String) - Method in class org.codehaus.activemq.ActiveMQSession
Creates a QueueReceiver object to receive messages from the specified queue using a message selector.
createReceiver(Queue) - Method in class org.codehaus.activemq.ra.JMSSessionProxy
 
createReceiver(Queue, String) - Method in class org.codehaus.activemq.ra.JMSSessionProxy
 
createRecoveryFailedException(Exception) - Method in class org.codehaus.activemq.store.howl.HowlMessageStore
 
createRecoveryFailedException(Exception) - Method in class org.codehaus.activemq.store.journal.JournalPersistenceAdapter
 
createReference(String, JNDIStorableInterface) - Static method in class org.codehaus.activemq.jndi.JNDIReferenceFactory
Create a Reference instance from a JNDIStorable object
createSecondaryConfig(SecondaryKeyCreator) - Method in class org.codehaus.activemq.store.bdb.BDbPersistenceAdapter
 
createSecondaryDatabase(String, Database, SecondaryConfig) - Method in class org.codehaus.activemq.store.bdb.BDbPersistenceAdapter
 
createSecondaryKey(SecondaryDatabase, DatabaseEntry, DatabaseEntry, DatabaseEntry) - Method in class org.codehaus.activemq.store.bdb.SequenceNumberCreator
 
createSecondaryKey(SecondaryDatabase, DatabaseEntry, DatabaseEntry, DatabaseEntry) - Method in class org.codehaus.activemq.store.bdb.StubSecondaryKeyGenerator
 
createSender(Queue) - Method in class org.codehaus.activemq.ActiveMQSession
Creates a QueueSender object to send messages to the specified queue.
createSender(Queue) - Method in class org.codehaus.activemq.ra.JMSSessionProxy
 
createServerSessionImpl() - Method in class org.codehaus.activemq.ra.ActiveMQAsfEndpointWorker.ServerSessionPoolImpl
 
createServerSide() - Method in class org.codehaus.activemq.transport.vm.VmTransportChannel
Creates the server side version of this client side channel.
createServerSocket(URI) - Method in class org.codehaus.activemq.transport.jxta.JxtaTransportServerChannel
 
createServerSocket(URI) - Method in class org.codehaus.activemq.transport.tcp.SfTransportServerChannelFactory
 
createServerSocket(URI) - Method in class org.codehaus.activemq.transport.tcp.TcpTransportServerChannel
Factory method to create a new ServerSocket
createServiceInfo(String, Map) - Method in class org.codehaus.activemq.transport.zeroconf.ZeroconfDiscoveryAgent
 
createSession(boolean, int) - Method in class org.codehaus.activemq.ActiveMQConnection
Creates a Session object.
createSession(boolean, int) - Method in class org.codehaus.activemq.ActiveMQXAConnection
 
createSession(boolean, int) - Method in class org.codehaus.activemq.ra.JMSConnectionProxy
 
createSession() - Method in class org.codehaus.activemq.util.JmsLogAppenderSupport
 
createSession() - Method in class org.codehaus.activemq.web.WebClient
 
createSessionConsumerPair(Destination) - Method in class org.codehaus.activemq.web.WebClient
 
createSocket(URI) - Method in class org.codehaus.activemq.transport.jxta.JxtaTransportChannel
 
createSocket(URI, URI) - Method in class org.codehaus.activemq.transport.jxta.JxtaTransportChannel
 
createSocket(int) - Method in class org.codehaus.activemq.transport.multicast.MulticastTransportChannel
 
createSocket(URI) - Method in class org.codehaus.activemq.transport.tcp.SfTransportChannelFactory
 
createSocket(URI, URI) - Method in class org.codehaus.activemq.transport.tcp.SfTransportChannelFactory
 
createSocket(URI) - Method in class org.codehaus.activemq.transport.tcp.TcpTransportChannel
Factory method to create a new socket
createSocket(URI, URI) - Method in class org.codehaus.activemq.transport.tcp.TcpTransportChannel
Factory method to create a new socket
createSocket(int) - Method in class org.codehaus.activemq.transport.udp.UdpTransportChannel
 
createStreamMessage() - Method in class org.codehaus.activemq.ActiveMQSession
Creates a StreamMessage object.
createStreamMessage() - Method in class org.codehaus.activemq.ra.JMSSessionProxy
 
createSubcontext(Name) - Method in class org.codehaus.activemq.jndi.ReadOnlyContext
 
createSubcontext(String) - Method in class org.codehaus.activemq.jndi.ReadOnlyContext
 
createSubscriber(Topic) - Method in class org.codehaus.activemq.ActiveMQSession
Creates a nondurable subscriber to the specified topic.
createSubscriber(Topic, String, boolean) - Method in class org.codehaus.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.codehaus.activemq.ra.JMSSessionProxy
 
createSubscriber(Topic, String, boolean) - Method in class org.codehaus.activemq.ra.JMSSessionProxy
 
createSubscription(Dispatcher, BrokerClient, ConsumerInfo, Filter) - Method in class org.codehaus.activemq.service.impl.DurableTopicSubscriptionContainerImpl
 
createSubscription(Dispatcher, BrokerClient, ConsumerInfo, Filter) - Method in class org.codehaus.activemq.service.impl.SubscriptionContainerImpl
 
createSubscriptionEntry() - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
 
createTask(Packet) - Static method in class org.codehaus.activemq.service.impl.PacketTransactionTask
 
createTemporaryName(String) - Static method in class org.codehaus.activemq.message.ActiveMQDestination
Create a temporary name from the clientId
createTemporaryQueue() - Method in class org.codehaus.activemq.ActiveMQSession
Creates a TemporaryQueue object.
createTemporaryQueue() - Method in class org.codehaus.activemq.ra.JMSSessionProxy
 
createTemporaryTopic() - Method in class org.codehaus.activemq.ActiveMQSession
Creates a TemporaryTopic object.
createTemporaryTopic() - Method in class org.codehaus.activemq.ra.JMSSessionProxy
 
createTextMessage() - Method in class org.codehaus.activemq.ActiveMQSession
Creates a TextMessage object.
createTextMessage(String) - Method in class org.codehaus.activemq.ActiveMQSession
Creates an initialized TextMessage object.
createTextMessage() - Method in class org.codehaus.activemq.ra.JMSSessionProxy
 
createTextMessage(String) - Method in class org.codehaus.activemq.ra.JMSSessionProxy
 
createTopic(String) - Method in class org.codehaus.activemq.ActiveMQSession
Creates a topic identity given a Topic name.
createTopic(String) - Method in class org.codehaus.activemq.jndi.ActiveMQInitialContextFactory
Factory method to create new Topic instances
createTopic(String) - Method in class org.codehaus.activemq.ra.JMSSessionProxy
 
createTopicConnection() - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
Create a JMS TopicConnection
createTopicConnection(String, String) - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
 
createTopicConnection() - Method in class org.codehaus.activemq.ActiveMQXAConnectionFactory
 
createTopicConnection(String, String) - Method in class org.codehaus.activemq.ActiveMQXAConnectionFactory
 
createTopicConnection() - Method in class org.codehaus.activemq.ra.ActiveMQConnectionFactory
 
createTopicConnection(String, String) - Method in class org.codehaus.activemq.ra.ActiveMQConnectionFactory
 
createTopicMessageContainer(String) - Method in class org.codehaus.activemq.service.impl.PersistenceAdapterSupport
 
createTopicMessageContainer(String) - Method in interface org.codehaus.activemq.store.PersistenceAdapter
Factory method to create a new durable topic based message container
createTopicMessageStore(String) - Method in interface org.codehaus.activemq.store.PersistenceAdapter
Factory method to create a new topic message store with the given destination name
createTopicMessageStore(String) - Method in class org.codehaus.activemq.store.bdb.BDbPersistenceAdapter
 
createTopicMessageStore(String) - Method in class org.codehaus.activemq.store.bdbn.BDbPersistenceAdapter
 
createTopicMessageStore(String) - Method in class org.codehaus.activemq.store.cache.CachePersistenceAdapter
 
createTopicMessageStore(String) - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
createTopicMessageStore(String) - Method in class org.codehaus.activemq.store.jdbc.JDBCPersistenceAdapter
 
createTopicMessageStore(String) - Method in class org.codehaus.activemq.store.jdbm.JdbmPersistenceAdapter
 
createTopicMessageStore(String) - Method in class org.codehaus.activemq.store.journal.JournalPersistenceAdapter
 
createTopicMessageStore(String) - Method in class org.codehaus.activemq.store.vm.VMPersistenceAdapter
 
createTopicSession(boolean, int) - Method in class org.codehaus.activemq.ActiveMQConnection
Creates a TopicSession object.
createTopicSession(boolean, int) - Method in class org.codehaus.activemq.ActiveMQXAConnection
 
createTopicSession(boolean, int) - Method in class org.codehaus.activemq.ra.JMSConnectionProxy
 
createTopics(Map, Hashtable) - Method in class org.codehaus.activemq.jndi.ActiveMQInitialContextFactory
 
createTransaction(DbEnv) - Static method in class org.codehaus.activemq.store.bdbn.BDbHelper
 
createTransactionLog() - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
createTransformer(Source) - Static method in class org.codehaus.activemq.spring.ActiveMQBeanDefinitionReader
 
createTransportChannel(String) - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
Factory method to create a TransportChannel from a URL
createTransportChannel() - Method in class org.codehaus.activemq.transport.http.HttpTunnelServlet
 
createTransportServerChannel(WireFormat, String) - Static method in class org.codehaus.activemq.broker.impl.BrokerConnectorImpl
Factory method ot create a transport channel
createURI(String, URI) - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
 
createURI(String) - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
 
createWebClient(HttpServletRequest) - Method in class org.codehaus.activemq.web.MessageServletSupport
 
createWireFormat() - Method in class org.codehaus.activemq.transport.http.HttpTransportConnector
 
createWriteException(Packet, Exception) - Method in class org.codehaus.activemq.store.howl.HowlMessageStore
 
createWriteException(Packet, Exception) - Method in class org.codehaus.activemq.store.journal.JournalPersistenceAdapter
 
createWriteException(String, Exception) - Method in class org.codehaus.activemq.store.journal.JournalPersistenceAdapter
 
createXAConnection() - Method in class org.codehaus.activemq.ActiveMQXAConnectionFactory
 
createXAConnection(String, String) - Method in class org.codehaus.activemq.ActiveMQXAConnectionFactory
 
createXAQueueConnection() - Method in class org.codehaus.activemq.ActiveMQXAConnectionFactory
 
createXAQueueConnection(String, String) - Method in class org.codehaus.activemq.ActiveMQXAConnectionFactory
 
createXAQueueSession() - Method in class org.codehaus.activemq.ActiveMQXAConnection
 
createXASession() - Method in class org.codehaus.activemq.ActiveMQXAConnection
 
createXATopicConnection() - Method in class org.codehaus.activemq.ActiveMQXAConnectionFactory
 
createXATopicConnection(String, String) - Method in class org.codehaus.activemq.ActiveMQXAConnectionFactory
 
createXATopicSession() - Method in class org.codehaus.activemq.ActiveMQXAConnection
 
createXATransaction(BrokerClient, ActiveMQXid) - Method in interface org.codehaus.activemq.service.TransactionManager
 
createXATransaction(BrokerClient, ActiveMQXid) - Method in class org.codehaus.activemq.service.impl.TransactionManagerImpl
 
createXStream() - Method in class org.codehaus.activemq.transport.xstream.XStreamWireFormat
 
createXslSource() - Method in class org.codehaus.activemq.spring.ActiveMQBeanDefinitionReader
Creates the XSL resource for the transformation
curChar - Variable in class org.codehaus.activemq.selector.SelectorParserTokenManager
 
curLexState - Variable in class org.codehaus.activemq.selector.SelectorParserTokenManager
 
currentToken - Variable in class org.codehaus.activemq.selector.ParseException
This is the last token that has been consumed successfully.
currentTransactionId - Variable in class org.codehaus.activemq.ActiveMQSession
 
currentURI - Variable in class org.codehaus.activemq.transport.composite.CompositeTransportChannel
 
cview - Variable in class org.codehaus.activemq.filter.MultiExpressionEvaluator.CacheExpression
 

D

DATA_RECORD_TYPE - Static variable in class org.codehaus.activemq.journal.impl.LogFile
 
DEFAULT - Static variable in interface org.codehaus.activemq.selector.SelectorParserConstants
 
DEFAULT_BACKLOG - Static variable in class org.codehaus.activemq.transport.tcp.TcpTransportServerChannel
 
DEFAULT_DELIVERY_MODE - Static variable in class org.codehaus.activemq.message.ActiveMQMessage
The message producer's default delivery mode is PERSISTENT.
DEFAULT_INITIAL_CAPACITY - Static variable in class org.codehaus.activemq.util.LRUCache
 
DEFAULT_LOAD_FACTOR - Static variable in class org.codehaus.activemq.util.LRUCache
 
DEFAULT_PASSWORD - Static variable in class org.codehaus.activemq.ActiveMQConnection
Default Password for the Connection
DEFAULT_PASSWORD - Static variable in class org.codehaus.activemq.axis.ActiveMQVendorAdapter
Specifies the default password
DEFAULT_PRIORITY - Static variable in class org.codehaus.activemq.message.ActiveMQMessage
The message producer's default priority is 4.
DEFAULT_TIME_TO_LIVE - Static variable in class org.codehaus.activemq.message.ActiveMQMessage
The message producer's default time to live is unlimited; the message never expires.
DEFAULT_URL - Static variable in class org.codehaus.activemq.ActiveMQConnection
Default URL for the ActiveMQ Broker
DEFAULT_USER - Static variable in class org.codehaus.activemq.ActiveMQConnection
Default UserName for the Connection
DEFAULT_USERNAME - Static variable in class org.codehaus.activemq.axis.ActiveMQVendorAdapter
Specifies the default user name
DISCONNECTED - Static variable in class org.codehaus.activemq.transport.TransportStatusEvent
The channel has been disconnected, but maybe reconnected
DOUBLE - Static variable in class org.codehaus.activemq.filter.ArithmeticExpression
 
DOUBLE - Static variable in class org.codehaus.activemq.message.ActiveMQMessage
 
DURABLE_UNSUBSCRIBE - Static variable in interface org.codehaus.activemq.message.Packet
Durable Unsubscribe message
DataContainer - class org.codehaus.activemq.message.util.DataContainer.
A DataContainer handles file persistence for a DiskBoundedQueue The DataContainer is a temporary data structure, that is only designed to exist for the lifetime of the application
DataContainer(File, String, int) - Constructor for class org.codehaus.activemq.message.util.DataContainer
Constructor for the data container
DefaultBroker - class org.codehaus.activemq.broker.impl.DefaultBroker.
The default Broker implementation
DefaultBroker(String, String) - Constructor for class org.codehaus.activemq.broker.impl.DefaultBroker
 
DefaultBroker(String) - Constructor for class org.codehaus.activemq.broker.impl.DefaultBroker
 
DefaultBroker(String, String, PersistenceAdapter) - Constructor for class org.codehaus.activemq.broker.impl.DefaultBroker
 
DefaultBroker(String, PersistenceAdapter) - Constructor for class org.codehaus.activemq.broker.impl.DefaultBroker
 
DefaultComparator - class org.codehaus.activemq.util.DefaultComparator.
A trivial default Comparator which only works on objects which are Comparable
DefaultComparator() - Constructor for class org.codehaus.activemq.util.DefaultComparator
 
DefaultConnectionManager - class org.codehaus.activemq.ra.DefaultConnectionManager.
A simple implementation of a ConnectionManager.
DefaultConnectionManager() - Constructor for class org.codehaus.activemq.ra.DefaultConnectionManager
 
DefaultJDBCAdapter - class org.codehaus.activemq.store.jdbc.adapter.DefaultJDBCAdapter.
Implements all the default JDBC operations that are used by the JDBCPersistenceAdapter.
DefaultJDBCAdapter(StatementProvider) - Constructor for class org.codehaus.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
DefaultJDBCAdapter() - Constructor for class org.codehaus.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
DefaultQueueList - class org.codehaus.activemq.service.impl.DefaultQueueList.
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.codehaus.activemq.service.impl.DefaultQueueList
Constructs an empty list.
DefaultQueueListEntry - class org.codehaus.activemq.service.impl.DefaultQueueListEntry.
Linked list entry class
DefaultQueueListEntry(Object, DefaultQueueListEntry, DefaultQueueListEntry) - Constructor for class org.codehaus.activemq.service.impl.DefaultQueueListEntry
Create a DefaultQueueListEntry for an object value
DefaultStatementProvider - class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider.
 
DefaultStatementProvider() - Constructor for class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
DefaultWireFormat - class org.codehaus.activemq.message.DefaultWireFormat.
Default implementation used for Java-Java protocols.
DefaultWireFormat() - Constructor for class org.codehaus.activemq.message.DefaultWireFormat
Default Constructor
DelegateCapacityMonitor - class org.codehaus.activemq.capacity.DelegateCapacityMonitor.
BasicCapacityMonitor implementation
DelegateCapacityMonitor() - Constructor for class org.codehaus.activemq.capacity.DelegateCapacityMonitor
Construct a DelegateCapacityMonitor
DelegateCapacityMonitor(String, CapacityMonitor) - Constructor for class org.codehaus.activemq.capacity.DelegateCapacityMonitor
Construct a DelegateCapacityMonitor
DestinationFilter - class org.codehaus.activemq.filter.DestinationFilter.
Represents a filter which only operates on Destinations
DestinationFilter() - Constructor for class org.codehaus.activemq.filter.DestinationFilter
 
DestinationMap - class org.codehaus.activemq.filter.DestinationMap.
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.codehaus.activemq.filter.DestinationMap
 
DestinationMapNode - class org.codehaus.activemq.filter.DestinationMapNode.
An implementation class used to implement DestinationMap
DestinationMapNode() - Constructor for class org.codehaus.activemq.filter.DestinationMapNode
 
DestinationPath - class org.codehaus.activemq.filter.DestinationPath.
Helper class for decomposing a Destination into a number of paths
DestinationPath() - Constructor for class org.codehaus.activemq.filter.DestinationPath
 
DiscoveryAgent - interface org.codehaus.activemq.transport.DiscoveryAgent.
An agent used to discover other instances of a service
DiscoveryAgentSupport - class org.codehaus.activemq.transport.DiscoveryAgentSupport.
A useful base class for DiscoveryAgent implementations
DiscoveryAgentSupport() - Constructor for class org.codehaus.activemq.transport.DiscoveryAgentSupport
 
DiscoveryEvent - class org.codehaus.activemq.transport.DiscoveryEvent.
Represents a discovery event containing the details of the service
DiscoveryEvent(DiscoveryAgent, String) - Constructor for class org.codehaus.activemq.transport.DiscoveryEvent
 
DiscoveryEvent(DiscoveryAgent, String, Map) - Constructor for class org.codehaus.activemq.transport.DiscoveryEvent
 
DiscoveryListener - interface org.codehaus.activemq.transport.DiscoveryListener.
A listener of services being added or removed from a nework
DiscoveryNetworkConnector - class org.codehaus.activemq.transport.DiscoveryNetworkConnector.
A NetworkConnector which uses discovery to find remote brokers to connect to
DiscoveryNetworkConnector(BrokerContainer) - Constructor for class org.codehaus.activemq.transport.DiscoveryNetworkConnector
 
DiscoveryTransportChannel - class org.codehaus.activemq.transport.DiscoveryTransportChannel.
A ReliableTransportChannel which uses a DiscoveryAgent to discover remote broker instances and dynamically connect to them.
DiscoveryTransportChannel(WireFormat, DiscoveryAgent) - Constructor for class org.codehaus.activemq.transport.DiscoveryTransportChannel
 
DiscoveryTransportChannelFactorySupport - class org.codehaus.activemq.transport.DiscoveryTransportChannelFactorySupport.
 
DiscoveryTransportChannelFactorySupport() - Constructor for class org.codehaus.activemq.transport.DiscoveryTransportChannelFactorySupport
 
DispatchWorker - class org.codehaus.activemq.service.impl.DispatchWorker.
A Dispatcher that polls for updates for active Message Consumers
DispatchWorker() - Constructor for class org.codehaus.activemq.service.impl.DispatchWorker
 
Dispatcher - interface org.codehaus.activemq.service.Dispatcher.
A dispatcher of messages to some JMS connection.
DispatcherImpl - class org.codehaus.activemq.service.impl.DispatcherImpl.
A dispatcher of messages to some JMS connection.
DispatcherImpl() - Constructor for class org.codehaus.activemq.service.impl.DispatcherImpl
 
Done() - Method in class org.codehaus.activemq.selector.SimpleCharStream
 
DuplicateDurableSubscriptionException - exception org.codehaus.activemq.DuplicateDurableSubscriptionException.
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 class org.codehaus.activemq.DuplicateDurableSubscriptionException
 
DurableQueueMessageContainer - class org.codehaus.activemq.service.impl.DurableQueueMessageContainer.
A default implemenation 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.codehaus.activemq.service.impl.DurableQueueMessageContainer
 
DurableQueueMessageContainer(PersistenceAdapter, MessageStore, String, QueueList, QueueList) - Constructor for class org.codehaus.activemq.service.impl.DurableQueueMessageContainer
 
DurableQueueMessageContainerManager - class org.codehaus.activemq.service.impl.DurableQueueMessageContainerManager.
A default Broker used for Queue messages
DurableQueueMessageContainerManager(PersistenceAdapter, RedeliveryPolicy) - Constructor for class org.codehaus.activemq.service.impl.DurableQueueMessageContainerManager
 
DurableQueueMessageContainerManager(PersistenceAdapter, SubscriptionContainer, FilterFactory, Dispatcher) - Constructor for class org.codehaus.activemq.service.impl.DurableQueueMessageContainerManager
 
DurableTopicMessageContainer - class org.codehaus.activemq.service.impl.DurableTopicMessageContainer.
A default implemenation of a Durable Topic based MessageContainer which acts as an adapter between the MessageContainerManager requirements and those of the persistent TopicMessageStore implementations.
DurableTopicMessageContainer(TopicMessageStore, String) - Constructor for class org.codehaus.activemq.service.impl.DurableTopicMessageContainer
 
DurableTopicMessageContainerManager - class org.codehaus.activemq.service.impl.DurableTopicMessageContainerManager.
A default Broker used for Topic messages for durable consumers
DurableTopicMessageContainerManager(PersistenceAdapter, RedeliveryPolicy) - Constructor for class org.codehaus.activemq.service.impl.DurableTopicMessageContainerManager
 
DurableTopicMessageContainerManager(PersistenceAdapter, SubscriptionContainer, FilterFactory, Dispatcher) - Constructor for class org.codehaus.activemq.service.impl.DurableTopicMessageContainerManager
 
DurableTopicSubscription - class org.codehaus.activemq.service.impl.DurableTopicSubscription.
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) - Constructor for class org.codehaus.activemq.service.impl.DurableTopicSubscription
 
DurableTopicSubscriptionContainerImpl - class org.codehaus.activemq.service.impl.DurableTopicSubscriptionContainerImpl.
An implemenation of SubscriptionContainerImpl for durable topic subscriptions
DurableTopicSubscriptionContainerImpl(RedeliveryPolicy) - Constructor for class org.codehaus.activemq.service.impl.DurableTopicSubscriptionContainerImpl
 
DurableTopicSubscriptionContainerImpl(Map, RedeliveryPolicy) - Constructor for class org.codehaus.activemq.service.impl.DurableTopicSubscriptionContainerImpl
 
DurableUnsubscribe - class org.codehaus.activemq.message.DurableUnsubscribe.
Command to remove a Durable Subscription
DurableUnsubscribe() - Constructor for class org.codehaus.activemq.message.DurableUnsubscribe
 
DurableUnsubscribeReader - class org.codehaus.activemq.message.DurableUnsubscribeReader.
Reads a DurableUnsubscribe object from a Stream
DurableUnsubscribeReader() - Constructor for class org.codehaus.activemq.message.DurableUnsubscribeReader
 
DurableUnsubscribeWriter - class org.codehaus.activemq.message.DurableUnsubscribeWriter.
Writes a DurableUnsubscribe object to a Stream
DurableUnsubscribeWriter() - Constructor for class org.codehaus.activemq.message.DurableUnsubscribeWriter
 
dataBuffer - Variable in class org.codehaus.activemq.journal.impl.Record
 
dataToObject(DataBuffer) - Method in class org.codehaus.activemq.store.bdbn.StringDataBinding
 
debugStream - Variable in class org.codehaus.activemq.selector.SelectorParserTokenManager
 
debugingWorkListener - Static variable in class org.codehaus.activemq.ra.ActiveMQPollingEndpointWorker
 
decrement() - Method in class org.codehaus.activemq.management.CountStatisticImpl
 
decrementIndent() - Method in class org.codehaus.activemq.util.IndentPrinter
 
decrementMemoryReferenceCount() - Method in class org.codehaus.activemq.message.AbstractPacket
Decrement reference count for bounded memory collections
decrementMemoryReferenceCount() - Method in interface org.codehaus.activemq.message.Packet
Decrement reference count for bounded memory collections
decrementMemoryUsed(Packet) - Method in class org.codehaus.activemq.message.util.MemoryBoundedQueueManager
 
decrementMessageCountAndMaybeDelete(MessageIdentity, MessageAck) - Method in interface org.codehaus.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, MessageAck) - Method in class org.codehaus.activemq.store.bdb.BDbTopicMessageStore
 
decrementMessageCountAndMaybeDelete(MessageIdentity, MessageAck) - Method in class org.codehaus.activemq.store.bdbn.BDbTopicMessageStore
 
decrementMessageCountAndMaybeDelete(MessageIdentity, MessageAck) - Method in class org.codehaus.activemq.store.cache.CacheTopicMessageStore
 
decrementMessageCountAndMaybeDelete(MessageIdentity, MessageAck) - Method in class org.codehaus.activemq.store.jdbc.JDBCTopicMessageStore
 
decrementMessageCountAndMaybeDelete(MessageIdentity, MessageAck) - Method in class org.codehaus.activemq.store.jdbm.JdbmTopicMessageStore
 
decrementMessageCountAndMaybeDelete(MessageIdentity, MessageAck) - Method in class org.codehaus.activemq.store.vm.VMTopicMessageStore
 
decrementReferenceCount() - Method in class org.codehaus.activemq.transport.NetworkMessageBridge
decrement number of references to this consumer
deepCopy() - Method in class org.codehaus.activemq.message.ActiveMQBytesMessage
 
deepCopy() - Method in class org.codehaus.activemq.message.ActiveMQMapMessage
 
deepCopy() - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
deepCopy() - Method in class org.codehaus.activemq.message.ActiveMQObjectMessage
 
deepCopy() - Method in class org.codehaus.activemq.message.ActiveMQStreamMessage
 
deepCopy() - Method in class org.codehaus.activemq.message.ActiveMQTextMessage
 
defaultDestination - Variable in class org.codehaus.activemq.ActiveMQMessageProducer
 
defaultLexState - Variable in class org.codehaus.activemq.selector.SelectorParserTokenManager
 
delete() - Method in class org.codehaus.activemq.message.ActiveMQTemporaryQueue
Deletes this temporary queue.
delete() - Method in class org.codehaus.activemq.message.ActiveMQTemporaryTopic
Deletes this temporary topic.
delete(MessageIdentity, MessageAck) - Method in interface org.codehaus.activemq.service.MessageContainer
Delete a message - if no
delete(MessageIdentity, MessageAck) - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
 
delete(MessageIdentity, MessageAck) - Method in class org.codehaus.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
 
delete(MessageIdentity, MessageAck) - Method in class org.codehaus.activemq.service.impl.DurableQueueMessageContainer
 
delete(MessageIdentity, MessageAck) - Method in class org.codehaus.activemq.service.impl.DurableTopicMessageContainer
 
delete(MessageAck) - Method in class org.codehaus.activemq.service.impl.MessagePointer
Notify the container it should delete the message
deleteAll() - Method in class org.codehaus.activemq.message.util.DataContainer
Delete all previous files of the same suffix in the directory
deleteSubscription(String, String) - Method in interface org.codehaus.activemq.broker.Broker
Delete a durable subscriber
deleteSubscription(String, String) - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
deleteSubscription(String, String) - Method in interface org.codehaus.activemq.service.MessageContainerManager
Delete a durable subscriber
deleteSubscription(String, String) - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageManager
Delete a durable subscriber
deleteSubscription(String, String) - Method in class org.codehaus.activemq.service.boundedvm.TransientTopicBoundedMessageManager
Delete a durable subscriber
deleteSubscription(String, String) - Method in class org.codehaus.activemq.service.impl.DurableQueueMessageContainerManager
Delete a durable subscriber
deleteSubscription(String, String) - Method in class org.codehaus.activemq.service.impl.DurableTopicMessageContainerManager
Delete a durable subscriber
deleteSubscription(String, String) - Method in class org.codehaus.activemq.service.impl.ProxyMessageContainerManager
 
deleteSubscription(String, String) - Method in class org.codehaus.activemq.service.impl.TransientTopicMessageContainerManager
Delete a durable subscriber
dequeue() - Method in interface org.codehaus.activemq.message.util.BoundedPacketQueue
 
dequeue(long) - Method in interface org.codehaus.activemq.message.util.BoundedPacketQueue
Dequeues a Packet from the head of the queue
dequeue() - Method in class org.codehaus.activemq.message.util.MemoryBoundedQueue
 
dequeue(long) - Method in class org.codehaus.activemq.message.util.MemoryBoundedQueue
Dequeues a Packet from the head of the queue
dequeue() - Method in class org.codehaus.activemq.message.util.SpooledBoundedPacketQueue
 
dequeue(long) - Method in class org.codehaus.activemq.message.util.SpooledBoundedPacketQueue
 
dequeueNoWait() - Method in class org.codehaus.activemq.ActiveMQSessionExecutor
 
dequeueNoWait() - Method in interface org.codehaus.activemq.message.util.BoundedPacketQueue
dequeues a Packet from the head of the queue
dequeueNoWait() - Method in class org.codehaus.activemq.message.util.MemoryBoundedQueue
dequeues a Packet from the head of the queue
dequeueNoWait() - Method in class org.codehaus.activemq.message.util.SpooledBoundedPacketQueue
 
deregisterClient(BrokerClient, ConnectionInfo) - Method in interface org.codehaus.activemq.broker.BrokerConnector
Deregister a Broker Client
deregisterClient(BrokerClient, ConnectionInfo) - Method in class org.codehaus.activemq.broker.impl.BrokerConnectorImpl
Deregister a Broker Client
deregisterConnection(BrokerClient, ConnectionInfo) - Method in interface org.codehaus.activemq.broker.BrokerContainer
un-registers a Connection
deregisterConnection(BrokerClient, ConnectionInfo) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
un-registers a Connection
deregisterConnector(String) - Method in class org.codehaus.activemq.broker.BrokerContext
 
deregisterContainer(String, BrokerContainer) - Method in class org.codehaus.activemq.broker.BrokerContext
 
deregisterMessageConsumer(BrokerClient, ConsumerInfo) - Method in interface org.codehaus.activemq.broker.BrokerConnector
De-register a MessageConsumer from the Broker
deregisterMessageConsumer(BrokerClient, ConsumerInfo) - Method in interface org.codehaus.activemq.broker.BrokerContainer
De-register a MessageConsumer from the Broker
deregisterMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.codehaus.activemq.broker.impl.BrokerConnectorImpl
De-register a MessageConsumer from the Broker
deregisterMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
De-register a MessageConsumer from the Broker
deregisterMessageProducer(BrokerClient, ProducerInfo) - Method in interface org.codehaus.activemq.broker.BrokerConnector
De-register a MessageProducer from the Broker
deregisterMessageProducer(BrokerClient, ProducerInfo) - Method in interface org.codehaus.activemq.broker.BrokerContainer
De-register a MessageProducer from the Broker
deregisterMessageProducer(BrokerClient, ProducerInfo) - Method in class org.codehaus.activemq.broker.impl.BrokerConnectorImpl
De-register a MessageProducer from the Broker
deregisterMessageProducer(BrokerClient, ProducerInfo) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
De-register a MessageProducer from the Broker
deregisterSession(BrokerClient, SessionInfo) - Method in interface org.codehaus.activemq.broker.BrokerConnector
De-register a client-side Session from the Broker (used for monitoring)
deregisterSession(BrokerClient, SessionInfo) - Method in interface org.codehaus.activemq.broker.BrokerContainer
De-register a client-side Session from the Broker (used for monitoring)
deregisterSession(BrokerClient, SessionInfo) - Method in class org.codehaus.activemq.broker.impl.BrokerConnectorImpl
De-register a client-side Session from the Broker (used for monitoring)
deregisterSession(BrokerClient, SessionInfo) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
De-register a client-side Session from the Broker (used for monitoring)
deserialize(byte[]) - Static method in class org.codehaus.activemq.util.SerializationHelper
 
destination - Variable in class org.codehaus.activemq.ActiveMQMessageConsumer
 
destinationMap - Variable in class org.codehaus.activemq.service.impl.DurableQueueMessageContainerManager
 
destinationName - Variable in class org.codehaus.activemq.store.jdbc.JDBCMessageStore
 
destroy() - Method in class org.codehaus.activemq.ra.ActiveMQManagedConnection
Close down the physical connection to the server.
destroySubcontext(Name) - Method in class org.codehaus.activemq.jndi.ReadOnlyContext
 
destroySubcontext(String) - Method in class org.codehaus.activemq.jndi.ReadOnlyContext
 
disableAppend() - Method in class org.codehaus.activemq.journal.impl.BatchedWrite
 
disable_tracing() - Method in class org.codehaus.activemq.selector.SelectorParser
 
dispatch(ActiveMQMessage) - Method in class org.codehaus.activemq.ActiveMQConnectionConsumer
Dispatch an ActiveMQMessage
dispatch(ActiveMQMessage) - Method in interface org.codehaus.activemq.ActiveMQMessageDispatcher
Dispatch an ActiveMQMessage
dispatch(ActiveMQMessage) - Method in class org.codehaus.activemq.ActiveMQSession
Dispatch an ActiveMQMessage
dispatch(ActiveMQMessage) - Method in interface org.codehaus.activemq.broker.BrokerClient
Dispatch an ActiveMQMessage to the end client
dispatch(ActiveMQMessage) - Method in class org.codehaus.activemq.broker.impl.BrokerClientImpl
Dispatch an ActiveMQMessage to the end client
dispatch - Variable in class org.codehaus.activemq.service.impl.SubscriptionImpl
 
dispatchMessages(Subscription, boolean) - Method in class org.codehaus.activemq.service.impl.DispatchWorker
 
dispatcher - Variable in class org.codehaus.activemq.service.impl.MessageContainerManagerSupport
 
divide(Number, Number) - Method in class org.codehaus.activemq.filter.ArithmeticExpression
 
doAcknowledge(boolean) - Method in class org.codehaus.activemq.ActiveMQSession
 
doAddBefore(QueueListSupport.Header, QueueListSupport.Node, Object) - Method in class org.codehaus.activemq.service.impl.QueueListSupport
 
doAddLast(Object, QueueListSupport.Header) - Method in class org.codehaus.activemq.service.impl.QueueListSupport
 
doAddMessage(Connection, long, String, String, byte[]) - Method in interface org.codehaus.activemq.store.jdbc.JDBCAdapter
 
doAddMessage(Connection, long, String, String, byte[]) - Method in class org.codehaus.activemq.store.jdbc.adapter.BlobJDBCAdapter
 
doAddMessage(Connection, long, String, String, byte[]) - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
doAddMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.codehaus.activemq.service.impl.DurableTopicMessageContainerManager
 
doAddXid(Connection, ActiveMQXid, byte[]) - Method in interface org.codehaus.activemq.store.jdbc.JDBCAdapter
 
doAddXid(Connection, ActiveMQXid, byte[]) - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
doAsyncMethodInvoke(Method, Object[]) - Method in class org.codehaus.activemq.util.AsyncProxy
 
doAsyncSend(Packet) - Method in class org.codehaus.activemq.transport.TransportChannelSupport
send a Packet to the raw underlying transport This method is here to allow specific implementations to override this method
doAsyncSend(Packet) - Method in class org.codehaus.activemq.transport.tcp.TcpTransportChannel
Actually performs the async send of a packet
doClose() - Method in class org.codehaus.activemq.ActiveMQSession
 
doClose(Exception) - Method in class org.codehaus.activemq.transport.vm.VmTransportChannel
 
doConsumePacket(Packet) - Method in class org.codehaus.activemq.transport.TransportChannelSupport
consume a packet from the channel
doConsumePacket(Packet, PacketListener) - Method in class org.codehaus.activemq.transport.TransportChannelSupport
 
doCreateTables(Connection) - Method in interface org.codehaus.activemq.store.jdbc.JDBCAdapter
 
doCreateTables(Connection) - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
doDelete(HttpServletRequest, HttpServletResponse) - Method in class org.codehaus.activemq.web.MessageServlet
Supports a HTTP DELETE to be equivlanent of consuming a message from a queue
doDispatch(ActiveMQMessage) - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueSubscription
Dispatch a message to the Consumer
doFail() - Method in class org.codehaus.activemq.gbean.ActiveMQConnectorGBean
 
doFail() - Method in class org.codehaus.activemq.gbean.ActiveMQContainerGBean
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.codehaus.activemq.transport.http.HttpTunnelServlet
 
doGet(HttpServletRequest, HttpServletResponse) - Method in class org.codehaus.activemq.web.MessageServlet
Reads a message from a destination up to some specific timeout period
doGetMessage(Connection, long) - Method in interface org.codehaus.activemq.store.jdbc.JDBCAdapter
 
doGetMessage(Connection, long) - Method in class org.codehaus.activemq.store.jdbc.adapter.BlobJDBCAdapter
 
doGetMessage(Connection, long) - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
doGetSubscriberEntry(Connection, String, String) - Method in interface org.codehaus.activemq.store.jdbc.JDBCAdapter
 
doGetSubscriberEntry(Connection, String, String) - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
doGetXids(Connection, List) - Method in interface org.codehaus.activemq.store.jdbc.JDBCAdapter
 
doGetXids(Connection, List) - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
doHandleReceipt(Packet) - Method in class org.codehaus.activemq.transport.TransportChannelSupport
 
doHandleWireFormat(Packet) - Method in class org.codehaus.activemq.transport.TransportChannelSupport
 
doLoadPreparedTransactions(Connection, TransactionManager) - Method in interface org.codehaus.activemq.store.jdbc.JDBCAdapter
 
doLoadPreparedTransactions(Connection, TransactionManager) - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
doMessageConsume(MessageAck, boolean) - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
Consume a message.
doMessageSend(BrokerClient, ActiveMQMessage) - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
doPoll() - Method in class org.codehaus.activemq.service.impl.DispatchWorker
 
doPost(HttpServletRequest, HttpServletResponse) - Method in class org.codehaus.activemq.transport.http.HttpTunnelServlet
 
doPost(HttpServletRequest, HttpServletResponse) - Method in class org.codehaus.activemq.web.MessageServlet
Sends a message to a destination
doReconnect() - Method in class org.codehaus.activemq.ActiveMQConnection
 
doReconnect(TransportChannel, long) - Method in class org.codehaus.activemq.transport.reliable.ReliableTransportChannel
 
doRecover(Connection, String, JDBCAdapter.MessageListResultHandler) - Method in interface org.codehaus.activemq.store.jdbc.JDBCAdapter
 
doRecover(Connection, String, JDBCAdapter.MessageListResultHandler) - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
doRecoverSubscription(Connection, String, String, JDBCAdapter.MessageListResultHandler) - Method in interface org.codehaus.activemq.store.jdbc.JDBCAdapter
 
doRecoverSubscription(Connection, String, String, JDBCAdapter.MessageListResultHandler) - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
doRemoveMessage(Connection, long) - Method in interface org.codehaus.activemq.store.jdbc.JDBCAdapter
 
doRemoveMessage(Connection, long) - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
doRemoveNode(QueueListSupport.Node) - Method in class org.codehaus.activemq.service.impl.QueueListSupport
 
doRemoveXid(Connection, ActiveMQXid) - Method in interface org.codehaus.activemq.store.jdbc.JDBCAdapter
 
doRemoveXid(Connection, ActiveMQXid) - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
doSetLastAck(Connection, String, String, long) - Method in interface org.codehaus.activemq.store.jdbc.JDBCAdapter
 
doSetLastAck(Connection, String, String, long) - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
doSetLastAcknowledgedMessageIdentity(Subscription, MessageIdentity) - Method in class org.codehaus.activemq.store.bdb.BDbTopicMessageStore
 
doSetSubscriberEntry(Connection, String, String, SubscriberEntry) - Method in interface org.codehaus.activemq.store.jdbc.JDBCAdapter
 
doSetSubscriberEntry(Connection, String, String, SubscriberEntry) - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
doStart() - Method in class org.codehaus.activemq.gbean.ActiveMQConnectorGBean
 
doStart() - Method in class org.codehaus.activemq.gbean.ActiveMQContainerGBean
 
doStartTransaction() - Method in class org.codehaus.activemq.ActiveMQSession
Send TransactionInfo to indicate transaction has started
doStartTransaction() - Method in class org.codehaus.activemq.ActiveMQXASession
This is called before transacted work is done by the session.
doStop() - Method in class org.codehaus.activemq.gbean.ActiveMQConnectorGBean
 
doStop() - Method in class org.codehaus.activemq.gbean.ActiveMQContainerGBean
 
drain() - Method in class org.codehaus.activemq.ra.CircularQueue
 
dump(IndentPrinter) - Method in class org.codehaus.activemq.journal.JournalStatsFilter
Writes the gathered statistics to the out object.
dump(IndentPrinter) - Method in class org.codehaus.activemq.management.JMSConnectionStatsImpl
 
dump(IndentPrinter) - Method in class org.codehaus.activemq.management.JMSConsumerStatsImpl
 
dump(IndentPrinter) - Method in class org.codehaus.activemq.management.JMSEndpointStatsImpl
 
dump(IndentPrinter) - Method in class org.codehaus.activemq.management.JMSProducerStatsImpl
 
dump(IndentPrinter) - Method in class org.codehaus.activemq.management.JMSSessionStatsImpl
 
dump(IndentPrinter) - Method in class org.codehaus.activemq.management.JMSStatsImpl
 
durableSubAcksTableName - Variable in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
durableUnsubscribe(BrokerClient, DurableUnsubscribe) - Method in interface org.codehaus.activemq.broker.BrokerConnector
Command to delete a durable topic subscription
durableUnsubscribe(BrokerClient, DurableUnsubscribe) - Method in interface org.codehaus.activemq.broker.BrokerContainer
Command to delete a durable topic subscription
durableUnsubscribe(BrokerClient, DurableUnsubscribe) - Method in class org.codehaus.activemq.broker.impl.BrokerConnectorImpl
Command to delete a durable topic subscription
durableUnsubscribe(BrokerClient, DurableUnsubscribe) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
Command to delete a durable topic subscription

E

EMBEDDED_BROKER - Static variable in class org.codehaus.activemq.axis.ActiveMQVendorAdapter
Specifies whether the broker is embedded
EMPTY_ARRAY - Static variable in interface org.codehaus.activemq.service.QueueList
 
END - Static variable in interface org.codehaus.activemq.message.TransactionType
End a transaction
END_OF_RECORD - Static variable in class org.codehaus.activemq.journal.impl.RecordFooter
 
EOF - Static variable in class org.codehaus.activemq.message.ActiveMQMessage
message property types
EOF - Static variable in interface org.codehaus.activemq.selector.SelectorParserConstants
 
ESCAPE - Static variable in interface org.codehaus.activemq.selector.SelectorParserConstants
 
EXPIRATION_INDEX - Static variable in class org.codehaus.activemq.message.ActiveMQMessage
 
EXPONENT - Static variable in interface org.codehaus.activemq.selector.SelectorParserConstants
 
EmberSupport - class org.codehaus.activemq.transport.ember.EmberSupport.
An abstract base class useful for implementation inheritence
EmberSupport() - Constructor for class org.codehaus.activemq.transport.ember.EmberSupport
 
EmberSupport(EIOGlobalContext, EIOPoolingStrategy) - Constructor for class org.codehaus.activemq.transport.ember.EmberSupport
 
EmberTransportChannel - class org.codehaus.activemq.transport.ember.EmberTransportChannel.
An EmberIO (using NIO) implementation of a TransportChannel
EmberTransportChannel(WireFormat) - Constructor for class org.codehaus.activemq.transport.ember.EmberTransportChannel
Construct basic helpers
EmberTransportChannel(WireFormat, EIOGlobalContext, EmberServiceController, ByteArrayServerClient) - Constructor for class org.codehaus.activemq.transport.ember.EmberTransportChannel
Connect to a remote Node - e.g.
EmberTransportChannelFactory - class org.codehaus.activemq.transport.ember.EmberTransportChannelFactory.
An EmberIO (using NIO) implementation of a TransportChannelFactory
EmberTransportChannelFactory() - Constructor for class org.codehaus.activemq.transport.ember.EmberTransportChannelFactory
 
EmberTransportChannelFactory(EIOGlobalContext, EIOPoolingStrategy) - Constructor for class org.codehaus.activemq.transport.ember.EmberTransportChannelFactory
 
EmberTransportServerChannel - class org.codehaus.activemq.transport.ember.EmberTransportServerChannel.
An EmberIO (using NIO) implementation of TransportServerChannel
EmberTransportServerChannel(WireFormat, URI, EIOGlobalContext, EmberServiceController) - Constructor for class org.codehaus.activemq.transport.ember.EmberTransportServerChannel
 
EmberTransportServerChannelFactory - class org.codehaus.activemq.transport.ember.EmberTransportServerChannelFactory.
An EmberIO (using NIO) implementation of a TransportServerChannelFactory
EmberTransportServerChannelFactory() - Constructor for class org.codehaus.activemq.transport.ember.EmberTransportServerChannelFactory
 
EmberTransportServerChannelFactory(EIOGlobalContext, EIOPoolingStrategy, EIOPoolingStrategy) - Constructor for class org.codehaus.activemq.transport.ember.EmberTransportServerChannelFactory
 
ExceptionTemplate - class org.codehaus.activemq.util.ExceptionTemplate.
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.codehaus.activemq.util.ExceptionTemplate
 
ExecutorHelper - class org.codehaus.activemq.util.ExecutorHelper.
A helper class for working with Executor objects
ExecutorHelper() - Constructor for class org.codehaus.activemq.util.ExecutorHelper
 
Expression - interface org.codehaus.activemq.filter.Expression.
Represents an expression
ExpressionFilter - class org.codehaus.activemq.filter.ExpressionFilter.
Represents a filter using an expression
ExpressionFilter(Expression) - Constructor for class org.codehaus.activemq.filter.ExpressionFilter
 
element - Variable in class org.codehaus.activemq.service.impl.DefaultQueueListEntry
 
embeddedBrokerInitParam - Static variable in class org.codehaus.activemq.web.WebClient
 
enableDetailedStats(boolean) - Method in class org.codehaus.activemq.journal.JournalStatsFilter
 
enable_tracing() - Method in class org.codehaus.activemq.selector.SelectorParser
 
encodeBinary(byte[]) - Method in class org.codehaus.activemq.transport.jabber.JabberWireFormat
 
end(Xid, int) - Method in class org.codehaus.activemq.ActiveMQXASession
 
endColumn - Variable in class org.codehaus.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.codehaus.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.
endpointActivation(MessageEndpointFactory, ActivationSpec) - Method in class org.codehaus.activemq.ra.ActiveMQResourceAdapter
 
endpointActivationKey - Variable in class org.codehaus.activemq.ra.ActiveMQBaseEndpointWorker
 
endpointDeactivation(MessageEndpointFactory, ActivationSpec) - Method in class org.codehaus.activemq.ra.ActiveMQResourceAdapter
 
endpointFactory - Variable in class org.codehaus.activemq.ra.ActiveMQBaseEndpointWorker
 
enqueue(Packet) - Method in interface org.codehaus.activemq.message.util.BoundedPacketQueue
Enqueue a Packet to this queue
enqueue(Packet) - Method in class org.codehaus.activemq.message.util.MemoryBoundedQueue
Enqueue a Packet to this queue
enqueue(Packet) - Method in class org.codehaus.activemq.message.util.SpooledBoundedPacketQueue
Place a Packet at the head of the Queue
enqueue(ActiveMQMessage) - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
enqueue a message for dispatching
enqueueFirst(Packet) - Method in class org.codehaus.activemq.message.util.MemoryBoundedQueue
Enqueue a Packet to the head of the queue
enqueueFirst(ActiveMQMessage) - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
enqueue a message for dispatching
enqueueFirstNoBlock(Packet) - Method in class org.codehaus.activemq.message.util.MemoryBoundedQueue
Enqueue a packet to the head of the queue with total disregard for memory constraints
enqueueNoBlock(Packet) - Method in interface org.codehaus.activemq.message.util.BoundedPacketQueue
Enqueue a Packet without checking usage limits
enqueueNoBlock(Packet) - Method in class org.codehaus.activemq.message.util.MemoryBoundedQueue
Enqueue a Packet without checking memory usage limits
enqueueNoBlock(Packet) - Method in class org.codehaus.activemq.message.util.SpooledBoundedPacketQueue
Enqueue a Packet without checking usage limits
ensureClientIDInitialised() - Method in class org.codehaus.activemq.ActiveMQConnection
 
ensureMulticastChannelIsAvailable(URI, TransportChannel, BrokerConnector, boolean) - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
 
ensureServerIsAvailable(URI, TransportChannel, BrokerConnector, boolean) - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
 
entry(int) - Method in class org.codehaus.activemq.service.impl.DefaultQueueList
 
environment - Variable in class org.codehaus.activemq.jndi.ReadOnlyContext
 
environment - Variable in class org.codehaus.activemq.store.bdbn.BDbPersistenceAdapter
 
eol - Variable in class org.codehaus.activemq.selector.ParseException
The end of line string for this machine.
equal(Object, Object) - Static method in class org.codehaus.activemq.service.impl.SubscriptionImpl
 
equalityExpression() - Method in class org.codehaus.activemq.selector.SelectorParser
 
equals(Object) - Method in class org.codehaus.activemq.filter.BinaryExpression
TODO: more efficient hashCode()
equals(Object) - Method in class org.codehaus.activemq.filter.ConstantExpression
TODO: more efficient hashCode()
equals(Object) - Method in class org.codehaus.activemq.filter.MultiExpressionEvaluator.CacheExpression
 
equals(Object) - Method in class org.codehaus.activemq.filter.PropertyExpression
 
equals(Object) - Method in class org.codehaus.activemq.filter.UnaryExpression
TODO: more efficient hashCode()
equals(Object) - Method in class org.codehaus.activemq.journal.howl.LongRecordLocation
 
equals(Object) - Method in class org.codehaus.activemq.journal.impl.RecordLocationImpl
 
equals(Object) - Method in class org.codehaus.activemq.message.AbstractPacket
Tests equality with another instance
equals(Object, Object) - Method in class org.codehaus.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.codehaus.activemq.message.ActiveMQDestination
if the object passed in is equivalent, return true
equals(Object) - Method in class org.codehaus.activemq.message.ActiveMQMessage
Returns true if this instance is equivalent to obj
equals(Object) - Method in class org.codehaus.activemq.message.ActiveMQXid
 
equals(Xid, Xid) - Static method in class org.codehaus.activemq.message.ActiveMQXid
Test for equivlance between two Xid
equals(byte[], byte[]) - Static method in class org.codehaus.activemq.message.ActiveMQXid
 
equals(Object) - Method in class org.codehaus.activemq.message.ConnectionInfo
Test for equality
equals(Object) - Method in class org.codehaus.activemq.message.ConsumerInfo
Test for equality
equals(Object) - Method in class org.codehaus.activemq.message.ProducerInfo
Test for equality
equals(Object) - Method in class org.codehaus.activemq.message.SessionInfo
Test for equality
equals(Object) - Method in class org.codehaus.activemq.message.TransactionInfo
Test for equality
equals(Object) - Method in class org.codehaus.activemq.message.XATransactionInfo
Test for equality
equals(Object) - Method in class org.codehaus.activemq.ra.ActiveMQConnectionRequestInfo
 
equals(Object) - Method in class org.codehaus.activemq.ra.ActiveMQEndpointActivationKey
 
equals(Object) - Method in class org.codehaus.activemq.service.MessageIdentity
 
equals(MessageIdentity) - Method in class org.codehaus.activemq.service.MessageIdentity
 
equals(Object) - Method in class org.codehaus.activemq.service.impl.MessageEntry
Tests equivalence with an other object
equals(Object) - Method in class org.codehaus.activemq.transport.NetworkMessageBridge
 
error - Variable in class org.codehaus.activemq.journal.impl.BatchedWrite
 
errorCode - Variable in class org.codehaus.activemq.selector.TokenMgrError
Indicates the reason why the exception is thrown.
establishConnection(long) - Method in class org.codehaus.activemq.transport.composite.CompositeTransportChannel
 
evaluate(Message) - Method in class org.codehaus.activemq.filter.ArithmeticExpression
 
evaluate(Object, Object) - Method in class org.codehaus.activemq.filter.ArithmeticExpression
 
evaluate(Message) - Method in class org.codehaus.activemq.filter.ComparisonExpression.LikeExpression
 
evaluate(Message) - Method in class org.codehaus.activemq.filter.ComparisonExpression
 
evaluate(Message) - Method in class org.codehaus.activemq.filter.ConstantExpression
 
evaluate(Message) - Method in interface org.codehaus.activemq.filter.Expression
 
evaluate(Message) - Method in class org.codehaus.activemq.filter.LogicExpression
 
evaluate(Boolean, Boolean) - Method in class org.codehaus.activemq.filter.LogicExpression
 
evaluate(Message) - Method in class org.codehaus.activemq.filter.MultiExpressionEvaluator.CacheExpression
 
evaluate(Message) - Method in class org.codehaus.activemq.filter.MultiExpressionEvaluator
Evaluates the message against all the Expressions added to this object.
evaluate(Message) - Method in class org.codehaus.activemq.filter.PropertyExpression
 
evaluateResultEvent(Expression, Message, Object) - Method in interface org.codehaus.activemq.filter.MultiExpressionEvaluator.ExpressionListener
 
execute(ActiveMQMessage) - Method in class org.codehaus.activemq.ActiveMQSessionExecutor
 
execute(Broker) - Method in interface org.codehaus.activemq.service.TransactionTask
 
execute(Broker) - Method in class org.codehaus.activemq.service.impl.MessageAckTransactionTask
 
execute(Broker) - Method in class org.codehaus.activemq.service.impl.RedeliverMessageTransactionTask
 
execute(Broker) - Method in class org.codehaus.activemq.service.impl.SendMessageTransactionTask
 
execute() - Method in interface org.codehaus.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
executeFirst(ActiveMQMessage) - Method in class org.codehaus.activemq.ActiveMQSessionExecutor
 
expectedTokenSequences - Variable in class org.codehaus.activemq.selector.ParseException
Each entry in this array is an array of integers.
expiredMessageCount - Variable in class org.codehaus.activemq.management.JMSEndpointStatsImpl
 
expression - Variable in class org.codehaus.activemq.filter.MultiExpressionEvaluator.ExpressionListenerSet
 
extractLong(DatabaseEntry) - Method in class org.codehaus.activemq.store.bdb.SequenceNumberCreator
 
extractMessage(DatabaseEntry) - Method in class org.codehaus.activemq.store.bdb.BDbMessageStore
 
extractMessage(Dbt) - Method in class org.codehaus.activemq.store.bdbn.BDbMessageStore
 
extractString(DatabaseEntry) - Method in class org.codehaus.activemq.store.bdb.BDbMessageStore
 
extractTransaction(DatabaseEntry) - Method in class org.codehaus.activemq.store.bdb.BDbPreparedTransactionStore
 
extractURI(List) - Method in class org.codehaus.activemq.transport.composite.CompositeTransportChannel
 
extractURI(List) - Method in class org.codehaus.activemq.transport.reliable.ReliableTransportChannel
 
extractXid(DatabaseEntry) - Method in class org.codehaus.activemq.store.bdb.BDbPreparedTransactionStore
 

F

FAILED - Static variable in class org.codehaus.activemq.transport.TransportStatusEvent
The channel has failed
FALSE - Static variable in class org.codehaus.activemq.filter.ConstantExpression
 
FALSE - Static variable in interface org.codehaus.activemq.selector.SelectorParserConstants
 
FINISHED_STATE - Static variable in class org.codehaus.activemq.service.impl.AbstractTransaction
 
FLOAT - Static variable in class org.codehaus.activemq.message.ActiveMQMessage
 
FLOATING_POINT_LITERAL - Static variable in interface org.codehaus.activemq.selector.SelectorParserConstants
 
FORGET - Static variable in interface org.codehaus.activemq.message.TransactionType
Forget a transaction
FactoryFinder - class org.codehaus.activemq.util.FactoryFinder.
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.codehaus.activemq.util.FactoryFinder
 
FileDataBlock - class org.codehaus.activemq.message.util.FileDataBlock.
Simply writes/reads data from a RandomAccessFile
FileDataBlock(File, long) - Constructor for class org.codehaus.activemq.message.util.FileDataBlock
Constructor
Filter - interface org.codehaus.activemq.filter.Filter.
Represents a subscription filter
FilterFactory - interface org.codehaus.activemq.filter.FilterFactory.
A factory of subscription Filter objects
FilterFactoryImpl - class org.codehaus.activemq.filter.FilterFactoryImpl.
A default implementation
FilterFactoryImpl() - Constructor for class org.codehaus.activemq.filter.FilterFactoryImpl
 
failureSleepTime - Variable in class org.codehaus.activemq.transport.composite.CompositeTransportChannel
 
fill(ByteBuffer) - Method in class org.codehaus.activemq.journal.impl.Record
 
filter - Variable in class org.codehaus.activemq.service.boundedvm.TransientSubscription
 
filter - Variable in class org.codehaus.activemq.service.impl.SubscriptionImpl
 
filterFactory - Variable in class org.codehaus.activemq.service.impl.DurableQueueMessageContainerManager
 
filterFactory - Variable in class org.codehaus.activemq.service.impl.DurableTopicMessageContainerManager
 
finalize() - Method in class org.codehaus.activemq.message.util.MemoryBoundedQueueManager
 
findClass(String) - Method in class org.codehaus.activemq.util.FactoryFinder
Loads the class for the given key
findSequenceNumber(String) - Method in class org.codehaus.activemq.store.bdb.BDbMessageStore
Iterates through from the start of the collection until the given message ID is found
findSequenceNumber(String) - Method in class org.codehaus.activemq.store.jdbm.JdbmMessageStore
Finds the sequence number for the given messageID
findWildcardMatches(ActiveMQDestination) - Method in class org.codehaus.activemq.filter.DestinationMap
 
fireConsumerInfo(BrokerClient, ConsumerInfo) - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
fireException(JMSException) - Method in class org.codehaus.activemq.transport.reliable.ReliableTransportChannel
Fire a JMSException to the exception listener
fireStatusEvent(URI, int) - Method in class org.codehaus.activemq.transport.TransportChannelSupport
Fire status event to any status event listeners
fireStatusEvent(TransportStatusEvent) - Method in class org.codehaus.activemq.transport.TransportChannelSupport
Fire status event to any status event listeners
flush() - Method in class org.codehaus.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.codehaus.activemq.util.IndentPrinter
 
footer - Variable in class org.codehaus.activemq.journal.impl.Record
 
footerBuffer - Variable in class org.codehaus.activemq.journal.impl.Record
 
force() - Method in class org.codehaus.activemq.journal.impl.Segment
 
forced() - Method in class org.codehaus.activemq.journal.impl.BatchedWrite
 
forget(Xid) - Method in class org.codehaus.activemq.ActiveMQXASession
 
freeze() - Method in class org.codehaus.activemq.jndi.ReadOnlyContext
 
fromBytes(byte[]) - Static method in class org.codehaus.activemq.message.ActiveMQXid
Deserializes the data into an Xid
fromBytes(byte[], int, int) - Method in class org.codehaus.activemq.message.WireFormat
Reads the packet from the given byte[]
fromBytes(byte[]) - Method in class org.codehaus.activemq.message.WireFormat
Reads the packet from the given byte[]
fromBytes(byte[]) - Static method in class org.codehaus.activemq.service.impl.PacketTransactionTask
 
fromBytes(byte[]) - Method in class org.codehaus.activemq.service.impl.QueueListSupport.Header
 
fromBytes(byte[]) - Method in class org.codehaus.activemq.service.impl.QueueListSupport.Node
 
fromBytes(byte[]) - Static method in class org.codehaus.activemq.service.impl.XATransactionCommand
 
fromString(String) - Method in class org.codehaus.activemq.message.TextWireFormat
Converts the String into a Packet
fromString(String) - Method in class org.codehaus.activemq.transport.xstream.XStreamWireFormat
 

G

GBEAN_INFO - Static variable in class org.codehaus.activemq.gbean.ActiveMQConnectorGBean
 
GBEAN_INFO - Static variable in class org.codehaus.activemq.gbean.ActiveMQContainerGBean
 
GET_RM_ID - Static variable in interface org.codehaus.activemq.message.TransactionType
Gets the unique id of the resource manager.
GET_TX_TIMEOUT - Static variable in interface org.codehaus.activemq.message.TransactionType
Get a the transaction timeout for the RM
GTransportChannel - class org.codehaus.activemq.transport.gnet.GTransportChannel.
An implementation of a TransportChannel which uses the Geronimo network layer for connectivity.
GTransportChannel(WireFormat, ThreadPool) - Constructor for class org.codehaus.activemq.transport.gnet.GTransportChannel
Construct basic helpers
GTransportChannel(WireFormat, Protocol, ThreadPool) - Constructor for class org.codehaus.activemq.transport.gnet.GTransportChannel
 
GTransportChannel(WireFormat, URI, URI, SelectorManager, ThreadPool, ClockPool) - Constructor for class org.codehaus.activemq.transport.gnet.GTransportChannel
 
GTransportChannelFactory - class org.codehaus.activemq.transport.gnet.GTransportChannelFactory.
An implementation of a TransportChannelFactory which uses the Geronimo network layer for connectivity.
GTransportChannelFactory() - Constructor for class org.codehaus.activemq.transport.gnet.GTransportChannelFactory
 
GTransportServerChannel - class org.codehaus.activemq.transport.gnet.GTransportServerChannel.
An implementation of TransportServerChannel which uses the Geronimo network layer for connectivity.
GTransportServerChannel(WireFormat, URI, SelectorManager, ThreadPool, ClockPool) - Constructor for class org.codehaus.activemq.transport.gnet.GTransportServerChannel
Default Constructor
GTransportServerChannelFactory - class org.codehaus.activemq.transport.gnet.GTransportServerChannelFactory.
An implementation of a TransportServerChannelFactory which uses the Geronimo network layer for connectivity.
GTransportServerChannelFactory() - Constructor for class org.codehaus.activemq.transport.gnet.GTransportServerChannelFactory
 
GetImage() - Method in class org.codehaus.activemq.selector.SimpleCharStream
 
GetSuffix(int) - Method in class org.codehaus.activemq.selector.SimpleCharStream
 
generateConsumerKey(String, String) - Static method in class org.codehaus.activemq.message.ConsumerInfo
Generate a primary key for a consumer from the clientId and consumerName
generateId() - Method in class org.codehaus.activemq.util.IdGenerator
Generate a unqiue id
generateParseException() - Method in class org.codehaus.activemq.selector.SelectorParser
 
generateSessionId() - Method in class org.codehaus.activemq.ActiveMQConnection
 
get(ActiveMQDestination) - Method in class org.codehaus.activemq.filter.DestinationMap
Looks up the value(s) matching the given Destination key.
get(int) - Method in class org.codehaus.activemq.message.util.MemoryBoundedQueue
retrieve a Packet at an indexed position in the queue
get() - Method in class org.codehaus.activemq.ra.CircularQueue
 
get(int) - Method in interface org.codehaus.activemq.service.QueueList
Returns the element at the specified position in this list.
get(int) - Method in class org.codehaus.activemq.service.impl.DefaultQueueList
 
get(int) - Method in class org.codehaus.activemq.service.impl.QueueListSupport
 
get(String) - Method in interface org.codehaus.activemq.store.cache.MessageCache
Gets a message that was previously put into this object.
get(String) - Method in class org.codehaus.activemq.store.cache.SimpleMessageCache
Gets a message that was previously put into this object.
get(int) - Method in class org.codehaus.activemq.util.BitArray
 
getAcceptPoolingStrategy() - Method in class org.codehaus.activemq.transport.ember.EmberTransportServerChannelFactory
 
getAckDatabase() - Method in class org.codehaus.activemq.store.jdbm.JdbmTopicMessageStore
 
getAcknowledgeMode() - Method in class org.codehaus.activemq.ActiveMQSession
Returns the acknowledgement mode of the session.
getAcknowledgeMode() - Method in class org.codehaus.activemq.ra.JMSSessionProxy
 
getActivationSpec() - Method in class org.codehaus.activemq.ra.ActiveMQEndpointActivationKey
 
getAddMessageStatment() - Method in interface org.codehaus.activemq.store.jdbc.StatementProvider
 
getAddMessageStatment() - Method in class org.codehaus.activemq.store.jdbc.adapter.CachingStatementProvider
 
getAddMessageStatment() - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getAddXidStatment() - Method in interface org.codehaus.activemq.store.jdbc.StatementProvider
 
getAddXidStatment() - Method in class org.codehaus.activemq.store.jdbc.adapter.CachingStatementProvider
 
getAddXidStatment() - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getAnyChildNode() - Method in class org.codehaus.activemq.filter.DestinationMapNode
Returns the node which represents all children (i.e.
getAppendOffset() - Method in class org.codehaus.activemq.journal.impl.Segment
 
getAppendSegmentIndex() - Method in class org.codehaus.activemq.journal.impl.LogFile
 
getAppendSegmentOffset() - Method in class org.codehaus.activemq.journal.impl.LogFile
 
getAveragePerSecond() - Method in class org.codehaus.activemq.management.TimeStatisticImpl
 
getAveragePerSecondExcludingMinMax() - Method in class org.codehaus.activemq.management.TimeStatisticImpl
 
getAverageTime() - Method in class org.codehaus.activemq.management.TimeStatisticImpl
 
getAverageTimeExcludingMinMax() - Method in class org.codehaus.activemq.management.TimeStatisticImpl
 
getAvgSyncedLatencyMs() - Method in class org.codehaus.activemq.journal.JournalStatsFilter
Gets the average sync write latency in ms.
getAvgUnSyncedLatencyMs() - Method in class org.codehaus.activemq.journal.JournalStatsFilter
Gets the average non sync write latency in ms.
getBackOffIncreaseRate() - Method in class org.codehaus.activemq.service.RedeliveryPolicy
 
getBacklog() - Method in class org.codehaus.activemq.transport.tcp.TcpTransportServerChannel
 
getBeginColumn() - Method in class org.codehaus.activemq.selector.SimpleCharStream
 
getBeginLine() - Method in class org.codehaus.activemq.selector.SimpleCharStream
 
getBinaryData(ResultSet, int) - Method in class org.codehaus.activemq.store.jdbc.adapter.BytesJDBCAdapter
 
getBinaryData(ResultSet, int) - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
getBinaryData(ResultSet, int) - Method in class org.codehaus.activemq.store.jdbc.adapter.StreamJDBCAdapter
 
getBinaryDataType() - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getBit(long) - Method in class org.codehaus.activemq.util.BitArrayBin
Get the boolean value at the index
getBitArray() - Method in class org.codehaus.activemq.message.AbstractPacket
 
getBits() - Method in class org.codehaus.activemq.util.BitArray
 
getBodyAsBytes() - Method in class org.codehaus.activemq.message.ActiveMQBytesMessage
 
getBodyAsBytes() - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
getBodyAsBytes() - Method in class org.codehaus.activemq.message.ActiveMQStreamMessage
 
getBodyLength() - Method in class org.codehaus.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.codehaus.activemq.ActiveMQConnectionFactory
Helper method to return the property value as a boolean flag
getBoolean(Properties, String, boolean) - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
Helper method to return the property value as a boolean flag
getBoolean(String) - Method in class org.codehaus.activemq.message.ActiveMQMapMessage
Returns the boolean value with the specified name.
getBooleanProperty(String) - Method in class org.codehaus.activemq.message.ActiveMQMessage
Returns the value of the boolean property with the specified name.
getBootstrapContext() - Method in class org.codehaus.activemq.ra.ActiveMQResourceAdapter
 
getBranchQualifier() - Method in class org.codehaus.activemq.message.ActiveMQXid
 
getBroker() - Method in interface org.codehaus.activemq.broker.BrokerContainer
 
getBroker() - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
 
getBroker() - Method in class org.codehaus.activemq.service.impl.AbstractTransaction
 
getBrokerCapacity() - Method in interface org.codehaus.activemq.broker.BrokerConnector
Get a hint about the broker capacity for more messages
getBrokerCapacity() - Method in class org.codehaus.activemq.broker.impl.BrokerConnectorImpl
Get a hint about the broker capacity for more messages
getBrokerClient() - Method in class org.codehaus.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
 
getBrokerClient(String) - Method in class org.codehaus.activemq.service.impl.PacketTransactionTask
 
getBrokerClusterName() - Method in interface org.codehaus.activemq.broker.Broker
 
getBrokerClusterName() - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
getBrokerConnector() - Method in interface org.codehaus.activemq.broker.BrokerClient
 
getBrokerConnector() - Method in class org.codehaus.activemq.broker.impl.BrokerClientImpl
 
getBrokerContainer() - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
 
getBrokerContainer() - Method in interface org.codehaus.activemq.broker.BrokerConnector
 
getBrokerContainer() - Method in class org.codehaus.activemq.broker.impl.BrokerConnectorImpl
 
getBrokerContainer() - Method in interface org.codehaus.activemq.gbean.ActiveMQContainer
 
getBrokerContainer() - Method in class org.codehaus.activemq.gbean.ActiveMQContainerGBean
 
getBrokerContainer() - Method in class org.codehaus.activemq.transport.NetworkChannel
 
getBrokerContainer() - Method in class org.codehaus.activemq.transport.NetworkConnector
 
getBrokerContainerByName(String, BrokerContainerFactory) - Method in class org.codehaus.activemq.broker.BrokerContext
 
getBrokerContainerFactory() - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
 
getBrokerContext() - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
Returns the context used to store broker containers and connectors which defaults to using the singleton
getBrokerInfo() - Method in interface org.codehaus.activemq.broker.BrokerConnector
 
getBrokerInfo() - Method in class org.codehaus.activemq.broker.impl.BrokerConnectorImpl
 
getBrokerMessageCapacity() - Method in class org.codehaus.activemq.message.Receipt
 
getBrokerName() - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
The name of the broker to use if creating an embedded broker
getBrokerName() - Method in interface org.codehaus.activemq.broker.Broker
 
getBrokerName() - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
getBrokerName() - Method in class org.codehaus.activemq.message.BrokerInfo
 
getBrokerName() - Method in class org.codehaus.activemq.message.Receipt
 
getBrokerName() - Method in class org.codehaus.activemq.spring.ActiveMQBeanDefinitionReader
 
getBrokerURL() - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
 
getBrokerXmlConfig() - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
 
getBrokersVisited() - Method in class org.codehaus.activemq.message.AbstractPacket
 
getBrokersVisitedAsString() - Method in class org.codehaus.activemq.message.AbstractPacket
 
getBrokersVisitedAsString() - Method in interface org.codehaus.activemq.message.Packet
 
getBufferClassName() - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
getBufferSize() - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
getByte(String) - Method in class org.codehaus.activemq.message.ActiveMQMapMessage
Returns the byte value with the specified name.
getByteBuffer() - Method in class org.codehaus.activemq.journal.impl.BatchedWrite
 
getByteBuffer() - Method in class org.codehaus.activemq.journal.impl.ByteBufferPool
Blocks until a ByteBuffer can be retreived from the pool.
getByteProperty(String) - Method in class org.codehaus.activemq.message.ActiveMQMessage
Returns the value of the byte property with the specified name.
getBytes(String) - Method in class org.codehaus.activemq.message.ActiveMQMapMessage
Returns the byte array value with the specified name.
getCacheSize() - Method in class org.codehaus.activemq.store.cache.SimpleCachePersistenceAdapter
 
getCapacity() - Method in interface org.codehaus.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.codehaus.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.codehaus.activemq.capacity.CapacityMonitorEvent
 
getCapacity() - Method in class org.codehaus.activemq.message.CapacityInfo
 
getChannel() - Method in interface org.codehaus.activemq.broker.BrokerClient
 
getChannel() - Method in class org.codehaus.activemq.broker.impl.BrokerClientImpl
 
getChannel() - Method in class org.codehaus.activemq.transport.composite.CompositeTransportChannel
 
getChannel() - Method in class org.codehaus.activemq.transport.http.HttpServerTransportChannel
 
getChannelConfiguration() - Method in class org.codehaus.activemq.transport.jgroups.JGroupsTransportChannelFactory
 
getChannelFactory() - Method in class org.codehaus.activemq.transport.jgroups.JGroupsTransportChannelFactory
 
getChannelName() - Method in class org.codehaus.activemq.transport.jgroups.JGroupsTransportChannelFactory
 
getChannelStatus() - Method in class org.codehaus.activemq.transport.TransportStatusEvent
 
getChar(String) - Method in class org.codehaus.activemq.message.ActiveMQMapMessage
Returns the Unicode character value with the specified name.
getChild(String) - Method in class org.codehaus.activemq.filter.DestinationMapNode
Returns the child node for the given named path or null if it does not exist
getChildDestinations() - Method in class org.codehaus.activemq.message.ActiveMQDestination
Returns a list of child destinations if this destination represents a composite destination.
getChildOrCreate(String) - Method in class org.codehaus.activemq.filter.DestinationMapNode
Returns the child node for the given named path, lazily creating one if it does not yet exist
getClientID() - Method in class org.codehaus.activemq.ActiveMQConnection
Gets the client identifier for this connection.
getClientID() - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
 
getClientID() - Method in class org.codehaus.activemq.DuplicateDurableSubscriptionException
 
getClientID() - Method in interface org.codehaus.activemq.broker.BrokerClient
 
getClientID() - Method in class org.codehaus.activemq.broker.impl.BrokerClientImpl
 
getClientID() - Method in class org.codehaus.activemq.ra.JMSConnectionProxy
 
getClientID() - Method in class org.codehaus.activemq.service.SubscriberEntry
 
getClientID() - Method in interface org.codehaus.activemq.transport.TransportChannel
 
getClientID() - Method in class org.codehaus.activemq.transport.TransportChannelSupport
 
getClientId(ActiveMQDestination) - Static method in class org.codehaus.activemq.message.ActiveMQDestination
From a temporary destination find the clientId of the Connection that created it
getClientId() - Method in class org.codehaus.activemq.message.ConnectionInfo
 
getClientId() - Method in class org.codehaus.activemq.message.ConsumerInfo
 
getClientId() - Method in class org.codehaus.activemq.message.DurableUnsubscribe
 
getClientId() - Method in class org.codehaus.activemq.message.ProducerInfo
 
getClientId() - Method in class org.codehaus.activemq.message.SessionInfo
 
getClientId() - Method in interface org.codehaus.activemq.service.Subscription
 
getClientId() - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
 
getClientVersion() - Method in class org.codehaus.activemq.message.ConnectionInfo
 
getClientid() - Method in class org.codehaus.activemq.ra.ActiveMQConnectionRequestInfo
 
getClientid() - Method in class org.codehaus.activemq.ra.ActiveMQResourceAdapter
 
getClockDaemon() - Method in class org.codehaus.activemq.store.journal.JournalPersistenceAdapter
 
getCloseCount() - Method in class org.codehaus.activemq.management.JCAConnectionPoolStatsImpl
 
getClosed() - Method in class org.codehaus.activemq.transport.http.HttpTransportChannelSupport
 
getClusterName() - Method in class org.codehaus.activemq.message.BrokerInfo
 
getClusterName() - Method in class org.codehaus.activemq.message.Receipt
 
getColumn() - Method in class org.codehaus.activemq.selector.SimpleCharStream
Deprecated.  
getConfig() - Method in class org.codehaus.activemq.store.bdb.BDbPersistenceAdapter
 
getConfiguration() - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
getConnection(Subject, ConnectionRequestInfo) - Method in class org.codehaus.activemq.ra.ActiveMQManagedConnection
 
getConnection() - Method in class org.codehaus.activemq.store.jdbc.JDBCPersistenceAdapter
 
getConnection() - Method in class org.codehaus.activemq.util.JmsLogAppenderSupport
 
getConnection() - Method in class org.codehaus.activemq.web.WebClient
 
getConnectionFactory() - Method in class org.codehaus.activemq.management.JCAConnectionStatsImpl
 
getConnectionMemoryLimit() - Method in class org.codehaus.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.codehaus.activemq.management.JCAStatsImpl
 
getConnectionStats() - Method in class org.codehaus.activemq.ActiveMQConnection
 
getConnections() - Method in class org.codehaus.activemq.management.JCAStatsImpl
 
getConnections() - Method in class org.codehaus.activemq.management.JMSStatsImpl
 
getConnectorByURL(String) - Method in class org.codehaus.activemq.broker.BrokerContext
 
getConsumer(Destination) - Method in class org.codehaus.activemq.web.WebClient
 
getConsumerId() - Method in class org.codehaus.activemq.ActiveMQMessageConsumer
 
getConsumerId() - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
getConsumerId() - Method in class org.codehaus.activemq.message.ConsumerInfo
 
getConsumerId() - Method in class org.codehaus.activemq.message.MessageAck
 
getConsumerId() - Method in interface org.codehaus.activemq.service.Subscription
 
getConsumerId() - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
 
getConsumerInfo() - Method in class org.codehaus.activemq.service.boundedvm.TransientSubscription
 
getConsumerKey() - Method in class org.codehaus.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.codehaus.activemq.ActiveMQMessageConsumer
 
getConsumerName() - Method in class org.codehaus.activemq.DuplicateDurableSubscriptionException
 
getConsumerName() - Method in class org.codehaus.activemq.message.ConsumerInfo
 
getConsumerName() - Method in class org.codehaus.activemq.service.SubscriberEntry
 
getConsumerNo() - Method in class org.codehaus.activemq.message.ConsumerInfo
 
getConsumerNos() - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
getConsumerNosAsString() - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
getConsumerNumber() - Method in class org.codehaus.activemq.ActiveMQMessageConsumer
 
getConsumerNumber() - Method in interface org.codehaus.activemq.service.Subscription
 
getConsumerNumber() - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
 
getConsumerStats() - Method in class org.codehaus.activemq.ActiveMQMessageConsumer
 
getConsumers() - Method in class org.codehaus.activemq.management.JMSSessionStatsImpl
 
getContainer(String) - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
 
getContainer(String) - Method in interface org.codehaus.activemq.service.MessageContainerManager
Allows the lookup of a specific named message container
getContainer(String) - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageManager
 
getContainer(String) - Method in class org.codehaus.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.codehaus.activemq.service.impl.DurableQueueMessageContainerManager
 
getContainer(String) - Method in class org.codehaus.activemq.service.impl.MessageContainerManagerSupport
 
getContainer() - Method in class org.codehaus.activemq.service.impl.MessagePointer
 
getContainer(String) - Method in class org.codehaus.activemq.service.impl.ProxyMessageContainerManager
 
getContainer() - Method in class org.codehaus.activemq.store.bdb.BDbMessageStore
 
getContainer() - Method in class org.codehaus.activemq.store.jdbm.JdbmMessageStore
 
getContainerManagerMap() - Method in interface org.codehaus.activemq.broker.Broker
 
getContainerManagerMap() - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
getContainerManagers() - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
getContainerNameDataType() - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getContentType(HttpServletRequest) - Method in class org.codehaus.activemq.web.MessageServlet
 
getContents() - Method in interface org.codehaus.activemq.message.util.BoundedPacketQueue
Retrieve a shallow copy of the contents as a list
getContents() - Method in class org.codehaus.activemq.message.util.MemoryBoundedQueue
Retrieve a shallow copy of the contents as a list
getContents() - Method in class org.codehaus.activemq.message.util.SpooledBoundedPacketQueue
 
getContexTransaction() - Method in interface org.codehaus.activemq.service.TransactionManager
 
getContexTransaction() - Method in class org.codehaus.activemq.service.impl.TransactionManagerImpl
 
getContext() - Method in class org.codehaus.activemq.transport.ember.EmberSupport
 
getController() - Method in class org.codehaus.activemq.transport.ember.EmberSupport
 
getCorrelationId() - Method in class org.codehaus.activemq.message.CapacityInfo
 
getCorrelationId() - Method in class org.codehaus.activemq.message.Receipt
 
getCount() - Method in class org.codehaus.activemq.management.CountStatisticImpl
 
getCount() - Method in class org.codehaus.activemq.management.TimeStatisticImpl
 
getCountFromId(String) - Static method in class org.codehaus.activemq.util.IdGenerator
From a generated id - return the generator count
getCreateCount() - Method in class org.codehaus.activemq.management.JCAConnectionPoolStatsImpl
 
getCreateDurableSubStatment() - Method in interface org.codehaus.activemq.store.jdbc.StatementProvider
 
getCreateDurableSubStatment() - Method in class org.codehaus.activemq.store.jdbc.adapter.CachingStatementProvider
 
getCreateDurableSubStatment() - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getCreateSchemaStatments() - Method in interface org.codehaus.activemq.store.jdbc.StatementProvider
 
getCreateSchemaStatments() - Method in class org.codehaus.activemq.store.jdbc.adapter.CachingStatementProvider
 
getCreateSchemaStatments() - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getCurrent() - Method in class org.codehaus.activemq.management.RangeStatisticImpl
 
getCurrentCapacity() - Method in class org.codehaus.activemq.capacity.BasicCapacityMonitor
Get the current capscity of the service as a percentage
getCurrentCapacity() - Method in interface org.codehaus.activemq.capacity.CapacityMonitor
Get the current capacity of the service as a percentage
getCurrentCapacity() - Method in class org.codehaus.activemq.capacity.DelegateCapacityMonitor
Get the current capscity of the service as a percentage
getCurrentValue() - Method in class org.codehaus.activemq.capacity.BasicCapacityMonitor
Get the current value of the CapacityMonitor
getCurrentValue() - Method in interface org.codehaus.activemq.capacity.CapacityMonitor
Get the current value of the CapacityMonitor
getCurrentValue() - Method in class org.codehaus.activemq.capacity.DelegateCapacityMonitor
Get the current value of the CapacityMonitor
getCurrentWireFormatVersion() - Method in class org.codehaus.activemq.message.DefaultWireFormat
 
getCurrentWireFormatVersion() - Method in class org.codehaus.activemq.message.WireFormat
 
getCurrentWireFormatVersion() - Method in interface org.codehaus.activemq.transport.TransportChannel
 
getCurrentWireFormatVersion() - Method in class org.codehaus.activemq.transport.composite.CompositeTransportChannel
 
getCurrentWireFormatVersion() - Method in class org.codehaus.activemq.transport.ember.EmberTransportChannel
 
getCurrentWireFormatVersion() - Method in class org.codehaus.activemq.transport.gnet.GTransportChannel
 
getCurrentWireFormatVersion() - Method in class org.codehaus.activemq.transport.http.HttpServerTransportChannel
 
getCurrentWireFormatVersion() - Method in class org.codehaus.activemq.transport.http.HttpTransportChannelSupport
 
getCurrentWireFormatVersion() - Method in class org.codehaus.activemq.transport.jabber.JabberWireFormat
 
getCurrentWireFormatVersion() - Method in class org.codehaus.activemq.transport.jgroups.JGroupsTransportChannel
 
getCurrentWireFormatVersion() - Method in class org.codehaus.activemq.transport.jrms.JRMSTransportChannel
 
getCurrentWireFormatVersion() - Method in class org.codehaus.activemq.transport.tcp.TcpTransportChannel
 
getCurrentWireFormatVersion() - Method in class org.codehaus.activemq.transport.udp.UdpTransportChannel
 
getCurrentWireFormatVersion() - Method in class org.codehaus.activemq.transport.vm.VmTransportChannel
 
getCurrentWireFormatVersion() - Method in class org.codehaus.activemq.transport.xstream.XStreamWireFormat
 
getCursorConfig() - Method in class org.codehaus.activemq.store.bdb.BDbMessageStore
 
getData() - Method in class org.codehaus.activemq.journal.impl.BatchedWrite
 
getData() - Method in class org.codehaus.activemq.message.util.WireByteArrayOutputStream
 
getDataFormat() - Method in class org.codehaus.activemq.store.bdbn.StringDataBinding
 
getDataSource() - Method in class org.codehaus.activemq.store.jdbc.JDBCPersistenceAdapter
 
getDatabase() - Method in class org.codehaus.activemq.store.bdb.BDbMessageStore
 
getDelegate() - Method in class org.codehaus.activemq.service.impl.ProxyMessageContainerManager
 
getDeliveryMode() - Method in class org.codehaus.activemq.ActiveMQMessageProducer
Gets the producer's default delivery mode.
getDescription() - Method in class org.codehaus.activemq.management.StatisticImpl
 
getDesendentValues() - Method in class org.codehaus.activemq.filter.DestinationMapNode
Returns a list of all the values from this node down the tree
getDestination() - Method in class org.codehaus.activemq.ActiveMQMessageConsumer
 
getDestination() - Method in class org.codehaus.activemq.ActiveMQMessageProducer
Gets the destination associated with this MessageProducer.
getDestination() - Method in class org.codehaus.activemq.management.JMSProducerStatsImpl
 
getDestination() - Method in class org.codehaus.activemq.message.ConsumerInfo
 
getDestination() - Method in class org.codehaus.activemq.message.MessageAck
 
getDestination() - Method in class org.codehaus.activemq.message.ProducerInfo
 
getDestination() - Method in class org.codehaus.activemq.service.SubscriberEntry
 
getDestination() - Method in interface org.codehaus.activemq.service.Subscription
 
getDestination() - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
 
getDestination() - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
 
getDestination() - Method in class org.codehaus.activemq.transport.NetworkMessageBridge
 
getDestination(LoggingEvent) - Method in class org.codehaus.activemq.util.JmsLogAppenderSupport
 
getDestination(WebClient, HttpServletRequest) - Method in class org.codehaus.activemq.web.MessageServletSupport
 
getDestination(WebClient, HttpServletRequest, String) - Method in class org.codehaus.activemq.web.MessageServletSupport
 
getDestinationContext(Hashtable) - Method in interface org.codehaus.activemq.broker.Broker
Returns the naming context of the destinations available in this broker
getDestinationContext(Hashtable) - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
getDestinationFilter() - Method in class org.codehaus.activemq.message.ActiveMQDestination
 
getDestinationFromURI(WebClient, HttpServletRequest) - Method in class org.codehaus.activemq.web.MessageServletSupport
 
getDestinationName() - Method in class org.codehaus.activemq.ra.ActiveMQActivationSpec
 
getDestinationName() - Method in interface org.codehaus.activemq.service.MessageContainer
 
getDestinationName() - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
 
getDestinationName() - Method in class org.codehaus.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
 
getDestinationName() - Method in class org.codehaus.activemq.service.impl.DurableQueueMessageContainer
 
getDestinationName() - Method in class org.codehaus.activemq.service.impl.DurableTopicMessageContainer
 
getDestinationPaths(String) - Static method in class org.codehaus.activemq.filter.DestinationPath
 
getDestinationPaths(Message) - Static method in class org.codehaus.activemq.filter.DestinationPath
 
getDestinationPaths(Destination) - Static method in class org.codehaus.activemq.filter.DestinationPath
 
getDestinationPaths() - Method in class org.codehaus.activemq.message.ActiveMQDestination
 
getDestinationType() - Method in class org.codehaus.activemq.message.ActiveMQDestination
 
getDestinationType() - Method in class org.codehaus.activemq.message.ActiveMQQueue
 
getDestinationType() - Method in class org.codehaus.activemq.message.ActiveMQTemporaryQueue
 
getDestinationType() - Method in class org.codehaus.activemq.message.ActiveMQTemporaryTopic
 
getDestinationType() - Method in class org.codehaus.activemq.message.ActiveMQTopic
 
getDestinationType() - Method in class org.codehaus.activemq.ra.ActiveMQActivationSpec
 
getDestinations() - Method in interface org.codehaus.activemq.service.MessageContainerManager
Returns an unmodifiable map, indexed by String name, of all the Destination objects available in this container
getDestinations() - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageManager
 
getDestinations() - Method in class org.codehaus.activemq.service.boundedvm.TransientTopicBoundedMessageManager
 
getDestinations() - Method in class org.codehaus.activemq.service.impl.MessageContainerManagerSupport
 
getDestinations() - Method in class org.codehaus.activemq.service.impl.ProxyMessageContainerManager
 
getDirectory() - Method in class org.codehaus.activemq.store.bdb.BDbPersistenceAdapter
 
getDirectory() - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
getDirectory() - Method in class org.codehaus.activemq.store.jdbm.JdbmPersistenceAdapter
 
getDirectory() - Method in class org.codehaus.activemq.store.journal.JournalPersistenceAdapter
 
getDisableMessageID() - Method in class org.codehaus.activemq.ActiveMQMessageProducer
Gets an indication of whether message IDs are disabled.
getDisableMessageTimestamp() - Method in class org.codehaus.activemq.ActiveMQMessageProducer
Gets an indication of whether message timestamps are disabled.
getDiscoveryAgent() - Method in interface org.codehaus.activemq.broker.BrokerContainer
Returns the discovery agent if one is available or null if discovery is not enabled
getDiscoveryAgent() - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
 
getDiscoveryAgent() - Method in class org.codehaus.activemq.transport.DiscoveryTransportChannel
 
getDiscoveryAgent() - Method in class org.codehaus.activemq.transport.DiscoveryTransportChannelFactorySupport
 
getDiscoveryListener() - Method in class org.codehaus.activemq.transport.DiscoveryAgentSupport
 
getDouble(String) - Method in class org.codehaus.activemq.message.ActiveMQMapMessage
Returns the double value with the specified name.
getDoubleProperty(String) - Method in class org.codehaus.activemq.message.ActiveMQMessage
Returns the value of the double property with the specified name.
getDropSchemaStatments() - Method in interface org.codehaus.activemq.store.jdbc.StatementProvider
 
getDropSchemaStatments() - Method in class org.codehaus.activemq.store.jdbc.adapter.CachingStatementProvider
 
getDropSchemaStatments() - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getDurableSubAcksTableName() - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getDurableSubscriptionCount() - Method in class org.codehaus.activemq.management.JMSSessionStatsImpl
 
getDurableSubscriptionName() - Method in class org.codehaus.activemq.ra.ActiveMQActivationSpec
 
getDurableTopicPrefetch() - Method in class org.codehaus.activemq.ActiveMQPrefetchPolicy
 
getElement() - Method in interface org.codehaus.activemq.service.QueueListEntry
Get the Object value for this entry
getElement() - Method in class org.codehaus.activemq.service.impl.DefaultQueueListEntry
Get the Object value for this entry
getElement() - Method in class org.codehaus.activemq.service.impl.QueueListSupport.Node
 
getEmbeddedBroker() - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
 
getEndColumn() - Method in class org.codehaus.activemq.selector.SimpleCharStream
 
getEndLine() - Method in class org.codehaus.activemq.selector.SimpleCharStream
 
getEndpointWorkerType() - Method in class org.codehaus.activemq.ra.ActiveMQResourceAdapter
 
getEntryBrokerName() - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
getEntryClusterName() - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
getEnumeration() - Method in class org.codehaus.activemq.ActiveMQQueueBrowser
Gets an enumeration for browsing the current queue messages in the order they would be received.
getEnvironment() - Method in class org.codehaus.activemq.jndi.ReadOnlyContext
 
getEnvironment() - Method in class org.codehaus.activemq.store.bdb.BDbPersistenceAdapter
 
getEstablishConnectionTimeout() - Method in class org.codehaus.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.codehaus.activemq.transport.reliable.ReliableTransportChannel
 
getException() - Method in class org.codehaus.activemq.message.Receipt
 
getExceptionListener() - Method in class org.codehaus.activemq.ActiveMQConnection
Gets the ExceptionListener object for this connection.
getExceptionListener() - Method in class org.codehaus.activemq.ra.JMSConnectionProxy
 
getExceptionListener() - Method in class org.codehaus.activemq.transport.TransportChannelSupport
 
getExceptionListener() - Method in class org.codehaus.activemq.util.MessageListenerSupport
 
getExpiredMessageCount() - Method in class org.codehaus.activemq.management.JMSEndpointStatsImpl
 
getExpiredMessageCount() - Method in class org.codehaus.activemq.management.JMSSessionStatsImpl
 
getExpression() - Method in class org.codehaus.activemq.filter.ExpressionFilter
 
getExpressionSymbol() - Method in class org.codehaus.activemq.filter.BinaryExpression
Returns the symbol that represents this binary expression.
getExpressionSymbol() - Method in class org.codehaus.activemq.filter.ComparisonExpression.LikeExpression
 
getExpressionSymbol() - Method in class org.codehaus.activemq.filter.MultiExpressionEvaluator.CacheExpression
 
getExpressionSymbol() - Method in class org.codehaus.activemq.filter.UnaryExpression
Returns the symbol that represents this binary expression.
getFactory(URI) - Static method in class org.codehaus.activemq.transport.TransportChannelProvider
 
getFactory(String) - Static method in class org.codehaus.activemq.transport.TransportServerChannelProvider
 
getFactoryStats() - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
 
getFailureSleepTime() - Method in class org.codehaus.activemq.transport.composite.CompositeTransportChannel
 
getFileMangerId() - Method in class org.codehaus.activemq.journal.impl.RecordLocationImpl
 
getFilter() - Method in class org.codehaus.activemq.service.boundedvm.TransientSubscription
 
getFilter() - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
 
getFindAllDurableSubMessagesStatment() - Method in interface org.codehaus.activemq.store.jdbc.StatementProvider
 
getFindAllDurableSubMessagesStatment() - Method in class org.codehaus.activemq.store.jdbc.adapter.CachingStatementProvider
 
getFindAllDurableSubMessagesStatment() - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getFindAllMessagesStatment() - Method in interface org.codehaus.activemq.store.jdbc.StatementProvider
 
getFindAllMessagesStatment() - Method in class org.codehaus.activemq.store.jdbc.adapter.CachingStatementProvider
 
getFindAllMessagesStatment() - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getFindAllTxStatment() - Method in interface org.codehaus.activemq.store.jdbc.StatementProvider
 
getFindAllTxStatment() - Method in class org.codehaus.activemq.store.jdbc.adapter.CachingStatementProvider
 
getFindAllTxStatment() - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getFindAllXidStatment() - Method in interface org.codehaus.activemq.store.jdbc.StatementProvider
 
getFindAllXidStatment() - Method in class org.codehaus.activemq.store.jdbc.adapter.CachingStatementProvider
 
getFindAllXidStatment() - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getFindDurableSubStatment() - Method in interface org.codehaus.activemq.store.jdbc.StatementProvider
 
getFindDurableSubStatment() - Method in class org.codehaus.activemq.store.jdbc.adapter.CachingStatementProvider
 
getFindDurableSubStatment() - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getFindLastSequenceId() - Method in interface org.codehaus.activemq.store.jdbc.StatementProvider
 
getFindLastSequenceId() - Method in class org.codehaus.activemq.store.jdbc.adapter.CachingStatementProvider
 
getFindLastSequenceId() - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getFindMessageSequenceIdStatment() - Method in interface org.codehaus.activemq.store.jdbc.StatementProvider
 
getFindMessageSequenceIdStatment() - Method in class org.codehaus.activemq.store.jdbc.adapter.CachingStatementProvider
 
getFindMessageSequenceIdStatment() - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getFindMessageStatment() - Method in interface org.codehaus.activemq.store.jdbc.StatementProvider
 
getFindMessageStatment() - Method in class org.codehaus.activemq.store.jdbc.adapter.CachingStatementProvider
 
getFindMessageStatment() - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getFindXidStatment() - Method in interface org.codehaus.activemq.store.jdbc.StatementProvider
 
getFindXidStatment() - Method in class org.codehaus.activemq.store.jdbc.adapter.CachingStatementProvider
 
getFindXidStatment() - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getFirst() - Method in interface org.codehaus.activemq.service.QueueList
Returns the first element in this list.
getFirst() - Method in class org.codehaus.activemq.service.impl.DefaultQueueList
 
getFirst() - Method in class org.codehaus.activemq.service.impl.QueueListSupport
 
getFirstActiveSegmentIndex() - Method in class org.codehaus.activemq.journal.impl.LogFile
 
getFirstEntry() - Method in interface org.codehaus.activemq.service.QueueList
Retrieve the first entry for the linked list
getFirstEntry() - Method in class org.codehaus.activemq.service.impl.DefaultQueueList
 
getFirstEntry() - Method in class org.codehaus.activemq.service.impl.QueueListSupport
 
getFirstException() - Method in class org.codehaus.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.
getFirstRecordLocation(byte) - Method in class org.codehaus.activemq.journal.impl.Segment
 
getFirstRecordLocationOfSecondActiveSegment(byte) - Method in class org.codehaus.activemq.journal.impl.LogFile
 
getFirstSequenceId() - Method in class org.codehaus.activemq.journal.impl.BatchedWrite
 
getFirstSequenceId() - Method in class org.codehaus.activemq.journal.impl.Segment
 
getFirstSequenceIdOfSegementIndex(byte) - Method in class org.codehaus.activemq.journal.impl.LogFile
 
getFloat(String) - Method in class org.codehaus.activemq.message.ActiveMQMapMessage
Returns the float value with the specified name.
getFloatProperty(String) - Method in class org.codehaus.activemq.message.ActiveMQMessage
Returns the value of the float property with the specified name.
getFlowControlTimeout() - Method in class org.codehaus.activemq.message.CapacityInfo
 
getFlushSleepTime() - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
getFormatId() - Method in class org.codehaus.activemq.message.ActiveMQXid
 
getFreePoolSize() - Method in class org.codehaus.activemq.management.JCAConnectionPoolStatsImpl
 
getGBeanInfo() - Static method in class org.codehaus.activemq.gbean.ActiveMQConnectorGBean
 
getGBeanInfo() - Static method in class org.codehaus.activemq.gbean.ActiveMQContainerGBean
 
getGlobalTransactionId() - Method in class org.codehaus.activemq.message.ActiveMQXid
 
getHeader() - Method in class org.codehaus.activemq.journal.impl.Record
 
getHeader() - Method in class org.codehaus.activemq.service.impl.QueueListSupport
Looks up the header object, lazily creating one if the current table is empty
getHighWaterMark() - Method in class org.codehaus.activemq.management.RangeStatisticImpl
 
getHostName() - Method in class org.codehaus.activemq.message.ConnectionInfo
 
getHostName() - Static method in class org.codehaus.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.codehaus.activemq.journal.impl.Segment
 
getId() - Method in class org.codehaus.activemq.message.AbstractPacket
 
getId() - Method in interface org.codehaus.activemq.message.Packet
 
getIdGenerator() - Method in class org.codehaus.activemq.ActiveMQMessageProducer
 
getIndentLevel() - Method in class org.codehaus.activemq.util.IndentPrinter
 
getIndex() - Method in class org.codehaus.activemq.journal.impl.Segment
 
getInfo() - Method in class org.codehaus.activemq.ra.ActiveMQResourceAdapter
 
getInitialContext(Hashtable) - Method in class org.codehaus.activemq.jndi.ActiveMQInitialContextFactory
 
getInitialContextFactoryName() - Method in class org.codehaus.activemq.util.JndiJmsLogAppender
 
getInitialDestinations() - Method in interface org.codehaus.activemq.store.PersistenceAdapter
Returns a map, indexed by String name, of all the Destination objects active on startup.
getInitialDestinations() - Method in class org.codehaus.activemq.store.bdb.BDbPersistenceAdapter
 
getInitialDestinations() - Method in class org.codehaus.activemq.store.bdbn.BDbPersistenceAdapter
 
getInitialDestinations() - Method in class org.codehaus.activemq.store.cache.CachePersistenceAdapter
 
getInitialDestinations() - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
getInitialDestinations() - Method in class org.codehaus.activemq.store.jdbc.JDBCPersistenceAdapter
 
getInitialDestinations() - Method in class org.codehaus.activemq.store.jdbm.JdbmPersistenceAdapter
 
getInitialDestinations() - Method in class org.codehaus.activemq.store.journal.JournalPersistenceAdapter
 
getInitialDestinations() - Method in class org.codehaus.activemq.store.vm.VMPersistenceAdapter
 
getInitialRedeliveryTimeout() - Method in class org.codehaus.activemq.service.RedeliveryPolicy
Returns the initial redelivery timeout
getInitialSegmentSize() - Method in class org.codehaus.activemq.journal.impl.LogFile
 
getInitialSegmentSize() - Method in class org.codehaus.activemq.journal.impl.LogFileManager
 
getInitializedClientID() - Method in class org.codehaus.activemq.ActiveMQConnection
Returns the clientID of the connection, forcing one to be generated if one has not yet been configured
getInstance() - Static method in class org.codehaus.activemq.broker.BrokerContext
 
getInt(String) - Method in class org.codehaus.activemq.message.ActiveMQMapMessage
Returns the int value with the specified name.
getInt(Map, String, int) - Static method in class org.codehaus.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.codehaus.activemq.message.ActiveMQMessage
Returns the value of the int property with the specified name.
getIoPoolingStrategy() - Method in class org.codehaus.activemq.transport.ember.EmberSupport
 
getJMSActiveMQDestination() - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
getJMSClientID() - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
getJMSCorrelationID() - Method in class org.codehaus.activemq.message.ActiveMQMessage
Gets the correlation ID for the message.
getJMSCorrelationIDAsBytes() - Method in class org.codehaus.activemq.message.ActiveMQMessage
Gets the correlation ID as an array of bytes for the message.
getJMSDeliveryMode() - Method in class org.codehaus.activemq.message.ActiveMQMessage
Gets the DeliveryMode value specified for this message.
getJMSDestination() - Method in class org.codehaus.activemq.message.ActiveMQMessage
Gets the Destination object for this message.
getJMSExpiration() - Method in class org.codehaus.activemq.message.ActiveMQMessage
Gets the message's expiration value.
getJMSMajorVersion() - Method in class org.codehaus.activemq.ActiveMQConnectionMetaData
Gets the JMS major version number.
getJMSMessageID() - Method in class org.codehaus.activemq.message.ActiveMQMessage
Gets the message ID.
getJMSMessageIdentity() - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
getJMSMinorVersion() - Method in class org.codehaus.activemq.ActiveMQConnectionMetaData
Gets the JMS minor version number.
getJMSPriority() - Method in class org.codehaus.activemq.message.ActiveMQMessage
Gets the message priority level.
getJMSProviderName() - Method in class org.codehaus.activemq.ActiveMQConnectionMetaData
Gets the JMS provider name.
getJMSRedelivered() - Method in class org.codehaus.activemq.message.ActiveMQMessage
Gets an indication of whether this message is being redelivered.
getJMSReplyTo() - Method in class org.codehaus.activemq.message.ActiveMQMessage
Gets the Destination object to which a reply to this message should be sent.
getJMSTimestamp() - Method in class org.codehaus.activemq.message.ActiveMQMessage
Gets the message timestamp.
getJMSType() - Method in class org.codehaus.activemq.message.ActiveMQMessage
Gets the message type identifier supplied by the client when the message was sent.
getJMSVersion() - Method in class org.codehaus.activemq.ActiveMQConnectionMetaData
Gets the JMS API version.
getJMSXPropertyNames() - Method in class org.codehaus.activemq.ActiveMQConnectionMetaData
Gets an enumeration of the JMSX property names.
getJmdns() - Method in class org.codehaus.activemq.transport.zeroconf.ZeroconfDiscoveryAgent
 
getJndiName() - Method in class org.codehaus.activemq.util.JndiJmsLogAppender
 
getKey() - Method in class org.codehaus.activemq.transport.ember.EmberSupport
 
getLast() - Method in interface org.codehaus.activemq.service.QueueList
Returns the last element in this list.
getLast() - Method in class org.codehaus.activemq.service.impl.DefaultQueueList
 
getLast() - Method in class org.codehaus.activemq.service.impl.QueueListSupport
 
getLastAcknowledgedMessageID(Subscription, MessageIdentity) - Method in class org.codehaus.activemq.store.bdb.BDbTopicMessageStore
 
getLastAcknowledgedMessageIdentity(Subscription) - Method in class org.codehaus.activemq.store.jdbm.JdbmTopicMessageStore
 
getLastEntry() - Method in interface org.codehaus.activemq.service.QueueList
Retrieve the last entry for the linked list
getLastEntry() - Method in class org.codehaus.activemq.service.impl.DefaultQueueList
 
getLastEntry() - Method in class org.codehaus.activemq.service.impl.QueueListSupport
 
getLastKey() - Method in class org.codehaus.activemq.store.bdb.SequenceNumberCreator
 
getLastMark() - Method in class org.codehaus.activemq.journal.impl.Segment
 
getLastMarkedRecordLocation(byte) - Method in class org.codehaus.activemq.journal.impl.LogFile
 
getLastMessageIdentity() - Method in interface org.codehaus.activemq.service.Subscription
Retreives the messageIdentity of the last message sent to this Queue based Subscription
getLastMessageIdentity() - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
 
getLastSampleTime() - Method in class org.codehaus.activemq.management.StatisticImpl
 
getLastSequenceId() - Method in class org.codehaus.activemq.journal.impl.BatchedWrite
 
getLastSequenceId() - Method in class org.codehaus.activemq.journal.impl.LogFile
 
getLastSequenceId() - Method in class org.codehaus.activemq.journal.impl.LogFileManager
 
getLastSequenceId() - Method in class org.codehaus.activemq.journal.impl.Segment
 
getLastSequenceId() - Method in class org.codehaus.activemq.util.LongSequenceGenerator
 
getLastSequenceNumber() - Method in class org.codehaus.activemq.store.jdbm.JdbmMessageStore
 
getLastestMessageIdentity() - Method in interface org.codehaus.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.codehaus.activemq.store.bdb.BDbTopicMessageStore
 
getLastestMessageIdentity() - Method in class org.codehaus.activemq.store.bdbn.BDbTopicMessageStore
 
getLastestMessageIdentity() - Method in class org.codehaus.activemq.store.cache.CacheTopicMessageStore
 
getLastestMessageIdentity() - Method in class org.codehaus.activemq.store.jdbc.JDBCTopicMessageStore
 
getLastestMessageIdentity() - Method in class org.codehaus.activemq.store.jdbm.JdbmTopicMessageStore
 
getLastestMessageIdentity() - Method in class org.codehaus.activemq.store.vm.VMTopicMessageStore
 
getLeft() - Method in class org.codehaus.activemq.filter.AndFilter
 
getLeft() - Method in class org.codehaus.activemq.filter.BinaryExpression
 
getLeft() - Method in class org.codehaus.activemq.filter.OrFilter
 
getLine() - Method in class org.codehaus.activemq.selector.SimpleCharStream
Deprecated.  
getLocalAddress() - Method in class org.codehaus.activemq.transport.zeroconf.ZeroconfDiscoveryAgent
 
getLocalBrokerName() - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
 
getLocalBrokerName() - Method in class org.codehaus.activemq.transport.DiscoveryNetworkConnector
 
getLocalBrokerName() - Method in class org.codehaus.activemq.transport.NetworkMessageBridge
 
getLocalConnectionURL() - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
 
getLocalDetails() - Method in class org.codehaus.activemq.transport.DiscoveryNetworkConnector
 
getLocalMemoryUsedByThisQueue() - Method in class org.codehaus.activemq.message.util.MemoryBoundedQueue
 
getLocalSession() - Method in class org.codehaus.activemq.transport.NetworkMessageBridge
 
getLocalTransaction() - Method in class org.codehaus.activemq.ra.ActiveMQManagedConnection
 
getLocalTransaction(String) - Method in interface org.codehaus.activemq.service.TransactionManager
 
getLocalTransaction(String) - Method in class org.codehaus.activemq.service.impl.TransactionManagerImpl
 
getLocalTransactionEventListener() - Method in class org.codehaus.activemq.ActiveMQSession
 
getLocalhost() - Method in class org.codehaus.activemq.transport.zeroconf.ZeroconfDiscoveryAgent
 
getLogDirectory() - Method in class org.codehaus.activemq.journal.impl.LogFile
 
getLogDirectory() - Method in class org.codehaus.activemq.journal.impl.LogFileManager
 
getLogFileDir() - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
getLogFileExt() - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
getLogFileName() - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
getLogWriter() - Method in class org.codehaus.activemq.ra.ActiveMQManagedConnection
 
getLogWriter() - Method in class org.codehaus.activemq.ra.ActiveMQManagedConnectionFactory
 
getLong(String) - Method in class org.codehaus.activemq.message.ActiveMQMapMessage
Returns the long value with the specified name.
getLongLocation() - Method in class org.codehaus.activemq.journal.howl.LongRecordLocation
 
getLongProperty(String) - Method in class org.codehaus.activemq.message.ActiveMQMessage
Returns the value of the long property with the specified name.
getLongTermPersistence() - Method in class org.codehaus.activemq.store.cache.CachePersistenceAdapter
 
getLongTermPersistence() - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
getLongTermPersistence() - Method in class org.codehaus.activemq.store.journal.JournalPersistenceAdapter
 
getLongTermStore() - Method in class org.codehaus.activemq.store.cache.CacheMessageStore
 
getLongTermStore() - Method in class org.codehaus.activemq.store.journal.JournalMessageStore
 
getLowWaterMark() - Method in class org.codehaus.activemq.management.RangeStatisticImpl
 
getLowerBound() - Method in class org.codehaus.activemq.management.BoundaryStatisticImpl
 
getLowerBound() - Method in class org.codehaus.activemq.management.BoundedRangeStatisticImpl
 
getManagedConnection() - Method in class org.codehaus.activemq.ra.JMSConnectionProxy
 
getManagedConnectionFactory() - Method in class org.codehaus.activemq.management.JCAConnectionStatsImpl
 
getManager() - Method in class org.codehaus.activemq.store.jdbm.JdbmPersistenceAdapter
 
getMapNames() - Method in class org.codehaus.activemq.message.ActiveMQMapMessage
Returns an Enumeration of all the names in the MapMessage object.
getMark() - Method in interface org.codehaus.activemq.journal.Journal
Obtains the mark that was set in the Journal.
getMark() - Method in class org.codehaus.activemq.journal.JournalStatsFilter
 
getMark() - Method in class org.codehaus.activemq.journal.howl.HowlJournal
 
getMark() - Method in class org.codehaus.activemq.journal.impl.BatchedWrite
 
getMark() - Method in class org.codehaus.activemq.journal.impl.JournalImpl
 
getMark() - Method in class org.codehaus.activemq.journal.impl.LogFileManager
 
getMark() - Method in class org.codehaus.activemq.journal.impl.Record
 
getMaxBlocksPerFile() - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
getMaxBuffers() - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
getMaxLogFiles() - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
getMaxOutstandingMessages() - Method in class org.codehaus.activemq.transport.tcp.TcpTransportServerChannel
 
getMaxTime() - Method in class org.codehaus.activemq.management.TimeStatisticImpl
 
getMaximumCacheSize() - Method in class org.codehaus.activemq.store.howl.HowlMessageStore
 
getMaximumCachedMessagesPerStore() - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
getMaximumMemoryUsage() - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
getMaximumRetries() - Method in class org.codehaus.activemq.transport.NetworkChannel
 
getMaximumRetries() - Method in class org.codehaus.activemq.transport.composite.CompositeTransportChannel
 
getMaximumRetryCount() - Method in class org.codehaus.activemq.service.RedeliveryPolicy
Returns the maximum retry count on a single message before its forwarded to a Dead Letter Queue
getMaximumTotalCachedMessages() - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
getMemoryBoundedQueue(String) - Method in class org.codehaus.activemq.ActiveMQConnection
 
getMemoryBoundedQueue(String) - Method in class org.codehaus.activemq.message.util.MemoryBoundedQueueManager
retrieve a named MemoryBoundedQueue or creates one if not found
getMemoryUsage() - Method in class org.codehaus.activemq.message.AbstractPacket
Get a hint about how much memory this Packet is consuming
getMemoryUsage() - Method in interface org.codehaus.activemq.message.Packet
Get a hint about how much memory this Packet is consuming
getMemoryUsageReferenceCount() - Method in class org.codehaus.activemq.message.AbstractPacket
 
getMemoryUsageReferenceCount() - Method in interface org.codehaus.activemq.message.Packet
 
getMessage() - Method in class org.codehaus.activemq.selector.ParseException
This method has the standard behavior when this object has been created using the standard constructors.
getMessage() - Method in class org.codehaus.activemq.selector.TokenMgrError
You can also modify the body of this method to customize your error messages.
getMessage(MessageIdentity) - Method in interface org.codehaus.activemq.service.MessageContainer
Return the ActiveMQMessage that matches the Id
getMessage(MessageIdentity) - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
 
getMessage(MessageIdentity) - Method in class org.codehaus.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
 
getMessage(MessageIdentity) - Method in class org.codehaus.activemq.service.impl.DurableQueueMessageContainer
 
getMessage(MessageIdentity) - Method in class org.codehaus.activemq.service.impl.DurableTopicMessageContainer
 
getMessage() - Method in class org.codehaus.activemq.service.impl.MessageEntry
 
getMessage(MessageIdentity) - Method in interface org.codehaus.activemq.store.MessageStore
Looks up a message using either the String messageID or the messageNumber.
getMessage(MessageIdentity) - Method in class org.codehaus.activemq.store.bdb.BDbMessageStore
 
getMessage(MessageIdentity) - Method in class org.codehaus.activemq.store.bdbn.BDbMessageStore
 
getMessage(MessageIdentity) - Method in class org.codehaus.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.codehaus.activemq.store.howl.HowlMessageStore
Lets ensure that readers don't block writers so there only synchronization on the cache and checkpointStore.
getMessage(MessageIdentity) - Method in class org.codehaus.activemq.store.jdbc.JDBCMessageStore
 
getMessage(MessageIdentity) - Method in class org.codehaus.activemq.store.jdbm.JdbmMessageStore
 
getMessage(MessageIdentity) - Method in class org.codehaus.activemq.store.journal.JournalMessageStore
 
getMessage(MessageIdentity) - Method in class org.codehaus.activemq.store.vm.VMMessageStore
 
getMessageAcknowledge() - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
getMessageBySequenceNumber(Long) - Method in class org.codehaus.activemq.store.jdbm.JdbmMessageStore
Looks up the message using the given sequence number
getMessageCount() - Method in class org.codehaus.activemq.management.JMSEndpointStatsImpl
 
getMessageCount() - Method in class org.codehaus.activemq.management.JMSSessionStatsImpl
 
getMessageCounts() - Method in class org.codehaus.activemq.store.jdbm.JdbmTopicMessageStore
 
getMessageEndpointFactory() - Method in class org.codehaus.activemq.ra.ActiveMQEndpointActivationKey
 
getMessageID() - Method in class org.codehaus.activemq.message.MessageAck
 
getMessageID() - Method in class org.codehaus.activemq.service.MessageIdentity
 
getMessageIdentity() - Method in class org.codehaus.activemq.message.MessageAck
 
getMessageIdentity() - Method in class org.codehaus.activemq.service.impl.MessagePointer
 
getMessageListener() - Method in class org.codehaus.activemq.ActiveMQMessageConsumer
Gets the message consumer's MessageListener.
getMessageListener() - Method in class org.codehaus.activemq.ActiveMQSession
Returns the session's distinguished message listener (optional).
getMessageListener() - Method in class org.codehaus.activemq.ra.JMSSessionProxy
 
getMessageRateTime() - Method in class org.codehaus.activemq.management.JMSSessionStatsImpl
 
getMessageSelector() - Method in class org.codehaus.activemq.ActiveMQMessageConsumer
Gets this message consumer's message selector expression.
getMessageSelector() - Method in class org.codehaus.activemq.ra.ActiveMQActivationSpec
 
getMessageSequenceId(Connection, String) - Method in interface org.codehaus.activemq.store.jdbc.JDBCAdapter
 
getMessageSequenceId(Connection, String) - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
getMessageTable() - Method in class org.codehaus.activemq.store.jdbm.JdbmMessageStore
 
getMessageTableName() - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getMessageWaitTime() - Method in class org.codehaus.activemq.management.JMSEndpointStatsImpl
 
getMessageWaitTime() - Method in class org.codehaus.activemq.management.JMSSessionStatsImpl
 
getMessagesToDispatch() - Method in interface org.codehaus.activemq.service.Subscription
Retrieve messages to dispatch
getMessagesToDispatch() - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
Retrieve messages to dispatch
getMessagesWithPrefetch() - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
 
getMetaData() - Method in class org.codehaus.activemq.ActiveMQConnection
Gets the metadata for this connection.
getMetaData() - Method in class org.codehaus.activemq.ra.ActiveMQManagedConnection
 
getMetaData() - Method in class org.codehaus.activemq.ra.JMSConnectionProxy
 
getMinBuffers() - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
getMinTime() - Method in class org.codehaus.activemq.management.TimeStatisticImpl
 
getMonitorName() - Method in class org.codehaus.activemq.capacity.CapacityMonitorEvent
 
getMsgIdDataType() - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getName() - Method in class org.codehaus.activemq.capacity.BasicCapacityMonitor
Get the name of the CapacityMonitor
getName() - Method in interface org.codehaus.activemq.capacity.CapacityMonitor
Get the name of the CapacityMonitor
getName() - Method in class org.codehaus.activemq.capacity.DelegateCapacityMonitor
Get the name of the CapacityMonitor
getName() - Method in class org.codehaus.activemq.filter.PropertyExpression
 
getName() - Method in class org.codehaus.activemq.management.StatisticImpl
 
getName() - Method in interface org.codehaus.activemq.message.util.BoundedPacketQueue
 
getName() - Method in class org.codehaus.activemq.message.util.MemoryBoundedQueue
 
getName() - Method in class org.codehaus.activemq.message.util.SpooledBoundedPacketQueue
 
getNameInNamespace() - Method in class org.codehaus.activemq.jndi.ReadOnlyContext
 
getNameParser(Name) - Method in class org.codehaus.activemq.jndi.ReadOnlyContext
 
getNameParser(String) - Method in class org.codehaus.activemq.jndi.ReadOnlyContext
 
getNetworkChannels() - Method in class org.codehaus.activemq.transport.NetworkConnector
 
getNetworkConnectors() - Method in interface org.codehaus.activemq.broker.BrokerContainer
Returns a list of NetworkConnector instances used to communicate with the network of Broker instances
getNetworkConnectors() - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
 
getNext() - Method in class org.codehaus.activemq.store.jdbc.adapter.CachingStatementProvider
 
getNextConsumerNumber() - Method in class org.codehaus.activemq.ActiveMQConnection
 
getNextDataRecordLocation(RecordLocationImpl) - Method in class org.codehaus.activemq.journal.impl.LogFile
 
getNextEntry(QueueListEntry) - Method in interface org.codehaus.activemq.service.QueueList
Retrieve the next entry after this entry
getNextEntry(QueueListEntry) - Method in class org.codehaus.activemq.service.impl.DefaultQueueList
 
getNextEntry(QueueListEntry) - Method in class org.codehaus.activemq.service.impl.QueueListSupport
 
getNextLocation() - Method in class org.codehaus.activemq.journal.impl.LogFile.RecordInfo
 
getNextRecordLocation(RecordLocation) - Method in interface org.codehaus.activemq.journal.Journal
Allows you to get the next RecordLocation after the location that is in the journal.
getNextRecordLocation(RecordLocation) - Method in class org.codehaus.activemq.journal.JournalStatsFilter
 
getNextRecordLocation(RecordLocation) - Method in class org.codehaus.activemq.journal.howl.HowlJournal
 
getNextRecordLocation(RecordLocation) - Method in class org.codehaus.activemq.journal.impl.JournalImpl
 
getNextRecordLocation(RecordLocationImpl) - Method in class org.codehaus.activemq.journal.impl.LogFileManager
 
getNextSequenceId() - Method in class org.codehaus.activemq.util.LongSequenceGenerator
 
getNextThreadId() - Static method in class org.codehaus.activemq.transport.vm.VmTransportChannel
 
getNextToken() - Method in class org.codehaus.activemq.selector.SelectorParser
 
getNextToken() - Method in class org.codehaus.activemq.selector.SelectorParserTokenManager
 
getNextTransactionId() - Method in class org.codehaus.activemq.ActiveMQSession
 
getNextTransactionId() - Method in class org.codehaus.activemq.ActiveMQXASession
 
getNoLocal() - Method in class org.codehaus.activemq.ActiveMQTopicSubscriber
Gets the NoLocal attribute for this subscriber.
getNoLocal() - Method in class org.codehaus.activemq.ra.ActiveMQActivationSpec
 
getNode(Long) - Method in class org.codehaus.activemq.service.impl.QueueListSupport
 
getNode(int) - Method in class org.codehaus.activemq.service.impl.QueueListSupport
 
getNode(QueueListSupport.Header, int) - Method in class org.codehaus.activemq.service.impl.QueueListSupport
 
getObject(String) - Method in class org.codehaus.activemq.message.ActiveMQMapMessage
Returns the value of the object with the specified name.
getObject() - Method in class org.codehaus.activemq.message.ActiveMQObjectMessage
Gets the serializable object containing this message's data.
getObjectInstance(Object, Name, Context, Hashtable) - Method in class org.codehaus.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.codehaus.activemq.message.ActiveMQMessage
Returns the value of the Java object property with the specified name.
getOrderedIndex() - Method in class org.codehaus.activemq.store.jdbm.JdbmMessageStore
 
getOrigin() - Method in class org.codehaus.activemq.management.JMSConsumerStatsImpl
 
getPacket() - Method in class org.codehaus.activemq.message.PacketFacade
 
getPacket() - Method in class org.codehaus.activemq.service.impl.PacketTransactionTask
 
getPacketListener() - Method in class org.codehaus.activemq.transport.TransportChannelSupport
 
getPacketType() - Method in class org.codehaus.activemq.message.ActiveMQBytesMessage
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.ActiveMQBytesMessageReader
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.ActiveMQBytesMessageWriter
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.ActiveMQMapMessage
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.ActiveMQMapMessageReader
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.ActiveMQMapMessageWriter
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.ActiveMQMessage
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.ActiveMQMessageReader
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.ActiveMQMessageWriter
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.ActiveMQObjectMessage
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.ActiveMQObjectMessageReader
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.ActiveMQObjectMessageWriter
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.ActiveMQStreamMessage
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.ActiveMQStreamMessageReader
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.ActiveMQStreamMessageWriter
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.ActiveMQTextMessage
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.ActiveMQTextMessageReader
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.ActiveMQTextMessageWriter
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.BrokerInfo
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.BrokerInfoReader
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.BrokerInfoWriter
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.CapacityInfo
 
getPacketType() - Method in class org.codehaus.activemq.message.CapacityInfoReader
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.CapacityInfoRequest
 
getPacketType() - Method in class org.codehaus.activemq.message.CapacityInfoRequestReader
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.CapacityInfoRequestWriter
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.CapacityInfoWriter
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.ConnectionInfo
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.ConnectionInfoReader
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.ConnectionInfoWriter
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.ConsumerInfo
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.ConsumerInfoReader
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.ConsumerInfoWriter
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.DurableUnsubscribe
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.DurableUnsubscribeReader
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.DurableUnsubscribeWriter
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.IntResponseReceipt
 
getPacketType() - Method in class org.codehaus.activemq.message.IntResponseReceiptReader
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.IntResponseReceiptWriter
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.MessageAck
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.MessageAckReader
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.MessageAckWriter
Return the type of Packet
getPacketType() - Method in interface org.codehaus.activemq.message.Packet
Return the type of Packet
getPacketType() - Method in interface org.codehaus.activemq.message.PacketReader
Return the type of Packet
getPacketType() - Method in interface org.codehaus.activemq.message.PacketWriter
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.ProducerInfo
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.ProducerInfoReader
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.ProducerInfoWriter
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.Receipt
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.ReceiptReader
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.ReceiptWriter
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.ResponseReceipt
 
getPacketType() - Method in class org.codehaus.activemq.message.ResponseReceiptReader
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.ResponseReceiptWriter
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.SessionInfo
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.SessionInfoReader
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.SessionInfoWriter
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.TransactionInfo
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.TransactionInfoReader
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.TransactionInfoWriter
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.WireFormatInfo
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.WireFormatInfoReader
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.WireFormatInfoWriter
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.XATransactionInfo
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.XATransactionInfoReader
Return the type of Packet
getPacketType() - Method in class org.codehaus.activemq.message.XATransactionInfoWriter
Return the type of Packet
getPacketTypeAsString(int) - Static method in class org.codehaus.activemq.message.AbstractPacket
 
getParent() - Method in class org.codehaus.activemq.management.CountStatisticImpl
 
getParent() - Method in class org.codehaus.activemq.management.TimeStatisticImpl
 
getPassword() - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
 
getPassword() - Method in class org.codehaus.activemq.message.ConnectionInfo
 
getPassword() - Method in class org.codehaus.activemq.ra.ActiveMQConnectionRequestInfo
 
getPassword() - Method in class org.codehaus.activemq.ra.ActiveMQResourceAdapter
 
getPassword() - Method in class org.codehaus.activemq.util.JmsLogAppender
 
getPassword() - Method in class org.codehaus.activemq.util.JndiJmsLogAppender
 
getPendingMessageCount() - Method in class org.codehaus.activemq.management.JMSEndpointStatsImpl
 
getPendingMessageCount() - Method in class org.codehaus.activemq.management.JMSSessionStatsImpl
 
getPersistenceAdapter() - Method in interface org.codehaus.activemq.broker.Broker
 
getPersistenceAdapter() - Method in interface org.codehaus.activemq.broker.BrokerContainer
Returns the persistence adapter
getPersistenceAdapter() - Method in class org.codehaus.activemq.broker.impl.BrokerContainerFactoryImpl
 
getPersistenceAdapter() - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
 
getPersistenceAdapter() - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
getPersistentKey() - Method in interface org.codehaus.activemq.service.Subscription
Returns the persistent key used to uniquely identify this durable topic subscription
getPersistentKey() - Method in class org.codehaus.activemq.service.impl.DurableTopicSubscription
 
getPersistentKey() - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
 
getPersistentQueueContainerManager() - Method in interface org.codehaus.activemq.broker.Broker
 
getPersistentQueueContainerManager() - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
getPersistentTopicContainerManager() - Method in interface org.codehaus.activemq.broker.Broker
 
getPersistentTopicContainerManager() - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
getPhysicalConnection() - Method in class org.codehaus.activemq.ra.ActiveMQManagedConnection
 
getPhysicalConnection() - Method in class org.codehaus.activemq.ra.ActiveMQResourceAdapter
 
getPhysicalName() - Method in class org.codehaus.activemq.message.ActiveMQDestination
 
getPhysicalSession() - Method in class org.codehaus.activemq.ra.ActiveMQManagedConnection
 
getPoolSize() - Method in class org.codehaus.activemq.management.JCAConnectionPoolStatsImpl
 
getPoolingStrategyByName(String) - Method in class org.codehaus.activemq.transport.ember.EmberSupport
 
getPostedMessageBody(HttpServletRequest) - Method in class org.codehaus.activemq.web.MessageServletSupport
 
getPrefetchNumber() - Method in class org.codehaus.activemq.ActiveMQMessageConsumer
 
getPrefetchNumber() - Method in class org.codehaus.activemq.message.ConsumerInfo
 
getPrefetchPolicy() - Method in class org.codehaus.activemq.ActiveMQConnection
 
getPreparedTransactionStore() - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
getPreparedTransactions(BrokerClient) - Method in interface org.codehaus.activemq.broker.Broker
gets a list of all the prepared xa transactions.
getPreparedTransactions(BrokerClient) - Method in interface org.codehaus.activemq.broker.BrokerConnector
Get all the Xids of the prepared XA transactions.
getPreparedTransactions(BrokerClient) - Method in interface org.codehaus.activemq.broker.BrokerContainer
Gets the prepared XA transactions.
getPreparedTransactions(BrokerClient) - Method in class org.codehaus.activemq.broker.impl.BrokerConnectorImpl
Gets the prepared XA transactions.
getPreparedTransactions(BrokerClient) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
Gets the prepared XA transactions.
getPreparedTransactions(BrokerClient) - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
Gets the prepared XA transactions.
getPreparedXATransactions() - Method in interface org.codehaus.activemq.service.TransactionManager
 
getPreparedXATransactions() - Method in class org.codehaus.activemq.service.impl.TransactionManagerImpl
 
getPrevEntry(QueueListEntry) - Method in interface org.codehaus.activemq.service.QueueList
Retrive the previous entry after this entry
getPrevEntry(QueueListEntry) - Method in class org.codehaus.activemq.service.impl.DefaultQueueList
 
getPrevEntry(QueueListEntry) - Method in class org.codehaus.activemq.service.impl.QueueListSupport
 
getPriority() - Method in class org.codehaus.activemq.ActiveMQMessageProducer
Gets the producer's default priority.
getPriority() - Method in class org.codehaus.activemq.transport.zeroconf.ZeroconfDiscoveryAgent
 
getProducer() - Method in class org.codehaus.activemq.util.JmsLogAppenderSupport
 
getProducerID() - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
getProducerId() - Method in class org.codehaus.activemq.ActiveMQMessageProducer
 
getProducerId() - Method in class org.codehaus.activemq.message.ProducerInfo
 
getProducerStats() - Method in class org.codehaus.activemq.ActiveMQMessageProducer
 
getProducers() - Method in class org.codehaus.activemq.management.JMSSessionStatsImpl
 
getProperties() - Method in class org.codehaus.activemq.jndi.JNDIBaseStorable
Get the properties from this instance for storing in JNDI
getProperties() - Method in interface org.codehaus.activemq.jndi.JNDIStorableInterface
Get the properties from this instance for storing in JNDI
getProperties() - Method in class org.codehaus.activemq.message.ActiveMQMessage
Retrieve the message properties as a Hashtable
getProperties() - Method in class org.codehaus.activemq.message.BrokerInfo
 
getProperties() - Method in class org.codehaus.activemq.message.ConnectionInfo
 
getPropertyNames() - Method in class org.codehaus.activemq.message.ActiveMQMessage
Returns an Enumeration of all the property names.
getProviderMajorVersion() - Method in class org.codehaus.activemq.ActiveMQConnectionMetaData
Gets the JMS provider major version number.
getProviderMinorVersion() - Method in class org.codehaus.activemq.ActiveMQConnectionMetaData
Gets the JMS provider minor version number.
getProviderURL() - Method in class org.codehaus.activemq.util.JndiJmsLogAppender
 
getProviderVersion() - Method in class org.codehaus.activemq.ActiveMQConnectionMetaData
Gets the JMS provider version.
getQueue() - Method in class org.codehaus.activemq.ActiveMQQueueBrowser
Gets the queue associated with this queue browser.
getQueue() - Method in class org.codehaus.activemq.ActiveMQQueueReceiver
Gets the Queue associated with this queue receiver.
getQueue() - Method in class org.codehaus.activemq.ActiveMQQueueSender
Gets the queue associated with this QueueSender.
getQueueBrowserPrefetch() - Method in class org.codehaus.activemq.ActiveMQPrefetchPolicy
 
getQueueConnectionFactory(HashMap) - Method in class org.codehaus.activemq.axis.ActiveMQVendorAdapter
 
getQueueName() - Method in class org.codehaus.activemq.message.ActiveMQQueue
Gets the name of this queue.
getQueuePrefetch() - Method in class org.codehaus.activemq.ActiveMQPrefetchPolicy
 
getQueuePrefix() - Method in class org.codehaus.activemq.jndi.ActiveMQInitialContextFactory
 
getQueueSession() - Method in class org.codehaus.activemq.ActiveMQXASession
 
getReadTimeout(HttpServletRequest) - Method in class org.codehaus.activemq.web.MessageServlet
 
getReader() - Method in class org.codehaus.activemq.spring.ActiveMQBeanFactory
 
getReceipt() - Method in class org.codehaus.activemq.message.ReceiptHolder
Get the Receipt
getReceipt(int) - Method in class org.codehaus.activemq.message.ReceiptHolder
wait upto timeout timeout ms to get a receipt
getReceiveCapacity() - Method in class org.codehaus.activemq.transport.vm.VmTransportChannel
 
getReceiveChannel() - Method in class org.codehaus.activemq.transport.vm.VmTransportChannel
 
getReceiveConnection() - Method in class org.codehaus.activemq.transport.http.HttpTransportChannel
 
getReceiveHttpClient() - Method in class org.codehaus.activemq.transport.http.HttpClientTransportChannel
 
getReconnectSleepTime() - Method in class org.codehaus.activemq.transport.NetworkChannel
 
getRedeliveryPolicy() - Method in interface org.codehaus.activemq.broker.Broker
 
getRedeliveryPolicy() - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
 
getRedeliveryPolicy() - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
getRedeliveryPolicy() - Method in class org.codehaus.activemq.service.impl.SubscriptionContainerImpl
 
getRedeliveryPolicy() - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
 
getReference() - Method in class org.codehaus.activemq.jndi.JNDIBaseStorable
Retrive a Reference for this instance to store in JNDI
getReference() - Method in class org.codehaus.activemq.ra.ActiveMQConnectionFactory
 
getRemoteBrokerName() - Method in class org.codehaus.activemq.transport.NetworkChannel
 
getRemotePassword() - Method in class org.codehaus.activemq.transport.DiscoveryNetworkConnector
 
getRemotePassword() - Method in class org.codehaus.activemq.transport.DiscoveryTransportChannel
 
getRemotePassword() - Method in class org.codehaus.activemq.transport.NetworkChannel
 
getRemoteSession() - Method in class org.codehaus.activemq.transport.NetworkMessageBridge
 
getRemoteURI() - Method in class org.codehaus.activemq.transport.TransportStatusEvent
 
getRemoteUrl() - Method in class org.codehaus.activemq.transport.http.HttpTransportChannelSupport
 
getRemoteUserName() - Method in class org.codehaus.activemq.transport.DiscoveryNetworkConnector
 
getRemoteUserName() - Method in class org.codehaus.activemq.transport.DiscoveryTransportChannel
 
getRemoteUserName() - Method in class org.codehaus.activemq.transport.NetworkChannel
 
getRemoveMessageStatment() - Method in interface org.codehaus.activemq.store.jdbc.StatementProvider
 
getRemoveMessageStatment() - Method in class org.codehaus.activemq.store.jdbc.adapter.CachingStatementProvider
 
getRemoveMessageStatment() - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getRemoveXidStatment() - Method in interface org.codehaus.activemq.store.jdbc.StatementProvider
 
getRemoveXidStatment() - Method in class org.codehaus.activemq.store.jdbc.adapter.CachingStatementProvider
 
getRemoveXidStatment() - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getResource() - Method in class org.codehaus.activemq.spring.ConfigurationParseException
 
getResource() - Method in class org.codehaus.activemq.spring.SpringBrokerContainerFactory
 
getResourceAdapter() - Method in class org.codehaus.activemq.ra.ActiveMQActivationSpec
 
getResourceAdapter() - Method in class org.codehaus.activemq.ra.ActiveMQManagedConnectionFactory
 
getResourceManagerId() - Method in class org.codehaus.activemq.ActiveMQXAConnection
 
getResourceManagerId(BrokerClient) - Method in interface org.codehaus.activemq.broker.BrokerConnector
Gets the unique id of the resource manager used for managing xa transactions.
getResourceManagerId(BrokerClient) - Method in class org.codehaus.activemq.broker.impl.BrokerConnectorImpl
 
getResourceName() - Method in class org.codehaus.activemq.message.CapacityInfo
 
getResult() - Method in class org.codehaus.activemq.message.IntResponseReceipt
 
getResult() - Method in class org.codehaus.activemq.message.ResponseReceipt
 
getResultBytes() - Method in class org.codehaus.activemq.message.ResponseReceipt
 
getRight() - Method in class org.codehaus.activemq.filter.AndFilter
 
getRight() - Method in class org.codehaus.activemq.filter.BinaryExpression
 
getRight() - Method in class org.codehaus.activemq.filter.OrFilter
 
getRight() - Method in class org.codehaus.activemq.filter.UnaryExpression
 
getRoundedCapacity() - Method in class org.codehaus.activemq.capacity.BasicCapacityMonitor
Calculates the capacity rounded down to the rounding factor
getRoundedCapacity() - Method in interface org.codehaus.activemq.capacity.CapacityMonitor
Calculates the capacity rounded down to the rounding factor
getRoundedCapacity() - Method in class org.codehaus.activemq.capacity.DelegateCapacityMonitor
Calculates the capacity rounded down to the rounding factor
getRoundingFactor() - Method in class org.codehaus.activemq.capacity.BasicCapacityMonitor
Get the rounding factor - default is 10
getRoundingFactor() - Method in interface org.codehaus.activemq.capacity.CapacityMonitor
Get the rounding factor - default is 10
getRoundingFactor() - Method in class org.codehaus.activemq.capacity.DelegateCapacityMonitor
Get the rounding factor - default is 10
getSecondaryDatabase() - Method in class org.codehaus.activemq.store.bdb.BDbMessageStore
 
getSecurityAdapter() - Method in interface org.codehaus.activemq.broker.Broker
Returns the security adapter used to authenticate and authorize access to JMS resources
getSecurityAdapter() - Method in interface org.codehaus.activemq.broker.BrokerContainer
Returns the security adapter used to authenticate and authorize access to JMS resources
getSecurityAdapter() - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
 
getSecurityAdapter() - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
getSecurityCredentials() - Method in class org.codehaus.activemq.util.JndiJmsLogAppender
 
getSecurityPrincipalName() - Method in class org.codehaus.activemq.util.JndiJmsLogAppender
 
getSeed() - Method in class org.codehaus.activemq.util.IdGenerator
 
getSeedFromId(String) - Static method in class org.codehaus.activemq.util.IdGenerator
From a generated id - return the seed (i.e.
getSegmentIndex() - Method in class org.codehaus.activemq.journal.impl.RecordLocationImpl
 
getSegmentOffset() - Method in class org.codehaus.activemq.journal.impl.RecordLocationImpl
 
getSelector() - Method in class org.codehaus.activemq.message.ConsumerInfo
 
getSelector() - Method in class org.codehaus.activemq.service.SubscriberEntry
 
getSelector() - Method in interface org.codehaus.activemq.service.Subscription
 
getSelector() - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
 
getSendCapacity() - Method in class org.codehaus.activemq.transport.vm.VmTransportChannel
 
getSendChannel() - Method in class org.codehaus.activemq.transport.vm.VmTransportChannel
 
getSendCloseTimeout() - Method in class org.codehaus.activemq.ActiveMQConnection
 
getSendConnection() - Method in class org.codehaus.activemq.transport.http.HttpTransportChannel
 
getSendConnectionInfoTimeout() - Method in class org.codehaus.activemq.ActiveMQConnection
 
getSendHttpClient() - Method in class org.codehaus.activemq.transport.http.HttpClientTransportChannel
 
getSequenceDataType() - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getSequenceGenerator() - Method in interface org.codehaus.activemq.store.jdbc.JDBCAdapter
 
getSequenceGenerator() - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
getSequenceId() - Method in class org.codehaus.activemq.journal.impl.RecordLocationImpl
 
getSequenceNumber() - Method in class org.codehaus.activemq.service.MessageIdentity
 
getSequenceNumberKey(MessageIdentity) - Method in class org.codehaus.activemq.store.bdb.BDbMessageStore
Returns the sequence number key for the given message identity.
getServerChannel() - Method in interface org.codehaus.activemq.broker.BrokerConnector
 
getServerChannel() - Method in class org.codehaus.activemq.broker.impl.BrokerConnectorImpl
 
getServerSession() - Method in class org.codehaus.activemq.ra.ActiveMQAsfEndpointWorker.ServerSessionPoolImpl
 
getServerSessionPool() - Method in class org.codehaus.activemq.ActiveMQConnectionConsumer
Gets the server session pool associated with this connection consumer.
getServerUrl() - Method in class org.codehaus.activemq.ra.ActiveMQConnectionRequestInfo
 
getServerUrl() - Method in class org.codehaus.activemq.ra.ActiveMQResourceAdapter
 
getServiceDetails() - Method in class org.codehaus.activemq.transport.DiscoveryEvent
 
getServiceName() - Method in class org.codehaus.activemq.transport.DiscoveryEvent
 
getSession() - Method in class org.codehaus.activemq.ActiveMQXASession
 
getSession() - Method in class org.codehaus.activemq.ra.ActiveMQAsfEndpointWorker.ServerSessionImpl
 
getSession() - Method in class org.codehaus.activemq.util.JmsLogAppenderSupport
 
getSession() - Method in class org.codehaus.activemq.web.WebClient
 
getSessionId() - Method in class org.codehaus.activemq.ActiveMQSession
 
getSessionId() - Method in class org.codehaus.activemq.message.ConsumerInfo
 
getSessionId() - Method in class org.codehaus.activemq.message.ProducerInfo
 
getSessionId() - Method in class org.codehaus.activemq.message.SessionInfo
 
getSessionStats() - Method in class org.codehaus.activemq.ActiveMQSession
 
getSessions() - Method in class org.codehaus.activemq.management.JMSConnectionStatsImpl
 
getShort(String) - Method in class org.codehaus.activemq.message.ActiveMQMapMessage
Returns the short value with the specified name.
getShortProperty(String) - Method in class org.codehaus.activemq.message.ActiveMQMessage
Returns the value of the short property with the specified name.
getSoTimeout() - Method in class org.codehaus.activemq.transport.tcp.TcpTransportChannel
 
getSocket() - Method in class org.codehaus.activemq.transport.tcp.TcpTransportChannel
 
getStartTime() - Method in class org.codehaus.activemq.ActiveMQMessageConsumer
 
getStartTime() - Method in class org.codehaus.activemq.ActiveMQMessageProducer
 
getStartTime() - Method in class org.codehaus.activemq.ActiveMQSession
 
getStartTime() - Method in class org.codehaus.activemq.management.StatisticImpl
 
getStartTime() - Method in class org.codehaus.activemq.message.BrokerInfo
 
getStartTime() - Method in class org.codehaus.activemq.message.ConnectionInfo
 
getStartTime() - Method in class org.codehaus.activemq.message.ConsumerInfo
 
getStartTime() - Method in class org.codehaus.activemq.message.ProducerInfo
 
getStartTime() - Method in class org.codehaus.activemq.message.SessionInfo
 
getStarted() - Method in class org.codehaus.activemq.transport.http.HttpTransportChannelSupport
 
getState() - Method in class org.codehaus.activemq.service.impl.AbstractTransaction
 
getStatistic(String) - Method in class org.codehaus.activemq.management.StatsImpl
 
getStatisticNames() - Method in class org.codehaus.activemq.management.StatsImpl
 
getStatistics() - Method in class org.codehaus.activemq.management.StatsImpl
 
getStats() - Method in class org.codehaus.activemq.ActiveMQConnection
 
getStats() - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
 
getStats() - Method in class org.codehaus.activemq.ActiveMQMessageConsumer
 
getStats() - Method in class org.codehaus.activemq.ActiveMQMessageProducer
 
getStats() - Method in class org.codehaus.activemq.ActiveMQSession
 
getStats() - Method in interface org.codehaus.activemq.management.StatsCapable
 
getStats() - Method in class org.codehaus.activemq.message.ActiveMQDestination
 
getStoreDirectory() - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
getString(String) - Method in class org.codehaus.activemq.message.ActiveMQMapMessage
Returns the String value with the specified name.
getString(Map, String) - Static method in class org.codehaus.activemq.util.MapHelper
Extracts the value from the map and coerces to a String
getStringProperty(String) - Method in class org.codehaus.activemq.message.ActiveMQMessage
Returns the value of the String property with the specified name.
getSubscriberEntry(ConsumerInfo) - Method in interface org.codehaus.activemq.store.TopicMessageStore
Finds the subscriber entry for the given consumer info
getSubscriberEntry(ConsumerInfo) - Method in class org.codehaus.activemq.store.bdb.BDbTopicMessageStore
 
getSubscriberEntry(ConsumerInfo) - Method in class org.codehaus.activemq.store.bdbn.BDbTopicMessageStore
 
getSubscriberEntry(ConsumerInfo) - Method in class org.codehaus.activemq.store.cache.CacheTopicMessageStore
 
getSubscriberEntry(ConsumerInfo) - Method in class org.codehaus.activemq.store.jdbc.JDBCTopicMessageStore
 
getSubscriberEntry(ConsumerInfo) - Method in class org.codehaus.activemq.store.jdbm.JdbmTopicMessageStore
 
getSubscriberEntry(ConsumerInfo) - Method in class org.codehaus.activemq.store.vm.VMTopicMessageStore
 
getSubscriberID() - Method in class org.codehaus.activemq.service.SubscriberEntry
 
getSubscriberName() - Method in class org.codehaus.activemq.message.DurableUnsubscribe
 
getSubscriberName() - Method in interface org.codehaus.activemq.service.Subscription
 
getSubscriberName() - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
 
getSubscription(String) - Method in interface org.codehaus.activemq.service.SubscriptionContainer
Gets the current subscription for the given consumerId if it is available
getSubscription(String) - Method in class org.codehaus.activemq.service.impl.SubscriptionContainerImpl
 
getSubscriptionEntry() - Method in interface org.codehaus.activemq.service.Subscription
Lazily creates the persistent entry representation of this subscription
getSubscriptionEntry() - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
 
getSubscriptionIdDataType() - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getSubscriptions(ActiveMQDestination) - Method in interface org.codehaus.activemq.service.SubscriptionContainer
 
getSubscriptions(ActiveMQDestination) - Method in class org.codehaus.activemq.service.impl.SubscriptionContainerImpl
 
getTable() - Method in class org.codehaus.activemq.message.ActiveMQMapMessage
 
getTablePrefix() - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getTempDir() - Method in interface org.codehaus.activemq.broker.Broker
Get a temp directory - used for spooling
getTempDir() - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
Get a temp directory - used for spooling
getText() - Method in class org.codehaus.activemq.filter.PrefixDestinationFilter
 
getText() - Method in class org.codehaus.activemq.filter.WildcardDestinationFilter
 
getText() - Method in class org.codehaus.activemq.message.ActiveMQTextMessage
Gets the string containing this message's data.
getThreadsWaitingForceThreshold() - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
getThroughputKps() - Method in class org.codehaus.activemq.journal.JournalStatsFilter
Gets the average throughput in k/s.
getThroughputRps() - Method in class org.codehaus.activemq.journal.JournalStatsFilter
Gets the average throughput in records/s.
getTimeToLive() - Method in class org.codehaus.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.
getToken(int) - Method in class org.codehaus.activemq.selector.SelectorParser
 
getTopic() - Method in class org.codehaus.activemq.ActiveMQTopicPublisher
Gets the topic associated with this TopicPublisher.
getTopic() - Method in class org.codehaus.activemq.ActiveMQTopicSubscriber
Gets the Topic associated with this subscriber.
getTopicConnectionFactory(HashMap) - Method in class org.codehaus.activemq.axis.ActiveMQVendorAdapter
 
getTopicName() - Method in class org.codehaus.activemq.message.ActiveMQTopic
Gets the name of this Topic.
getTopicPrefetch() - Method in class org.codehaus.activemq.ActiveMQPrefetchPolicy
 
getTopicPrefix() - Method in class org.codehaus.activemq.jndi.ActiveMQInitialContextFactory
 
getTopicSession() - Method in class org.codehaus.activemq.ActiveMQXASession
 
getTotalMemoryUsedSize() - Method in class org.codehaus.activemq.message.util.MemoryBoundedQueueManager
 
getTotalSegements() - Method in class org.codehaus.activemq.journal.impl.LogFile
 
getTotalSegements() - Method in class org.codehaus.activemq.journal.impl.LogFileManager
 
getTotalTime() - Method in class org.codehaus.activemq.management.TimeStatisticImpl
 
getTransacted() - Method in class org.codehaus.activemq.ActiveMQSession
Indicates whether the session is in transacted mode.
getTransacted() - Method in class org.codehaus.activemq.ActiveMQXASession
 
getTransacted() - Method in class org.codehaus.activemq.ra.JMSSessionProxy
 
getTransaction() - Static method in class org.codehaus.activemq.store.bdb.BDbHelper
 
getTransaction() - Static method in class org.codehaus.activemq.store.bdbn.BDbHelper
 
getTransactionConfig() - Method in class org.codehaus.activemq.store.bdb.BDbPersistenceAdapter
 
getTransactionCount() - Static method in class org.codehaus.activemq.store.bdb.BDbHelper
 
getTransactionCount() - Static method in class org.codehaus.activemq.store.bdbn.BDbHelper
 
getTransactionId() - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
getTransactionId() - Method in class org.codehaus.activemq.message.MessageAck
 
getTransactionId() - Method in class org.codehaus.activemq.message.TransactionInfo
 
getTransactionLog() - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
getTransactionManager() - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
getTransactionTimeout() - Method in class org.codehaus.activemq.ActiveMQXASession
 
getTransactionTimeout() - Method in class org.codehaus.activemq.message.XATransactionInfo
 
getTransientQueueContainerManager() - Method in interface org.codehaus.activemq.broker.Broker
 
getTransientQueueContainerManager() - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
getTransientTopicContainerManager() - Method in interface org.codehaus.activemq.broker.Broker
 
getTransientTopicContainerManager() - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
getTransportChannel() - Method in class org.codehaus.activemq.ActiveMQConnection
 
getTransportChannel(HttpServletRequest) - Method in class org.codehaus.activemq.transport.http.HttpTunnelServlet
 
getTransportChannelListener() - Method in class org.codehaus.activemq.transport.TransportChannelSupport
 
getTransportChannelListener() - Method in class org.codehaus.activemq.transport.TransportServerChannelSupport
 
getTransportConnectors() - Method in interface org.codehaus.activemq.broker.BrokerContainer
Returns the transport connectors used to communicate with clients
getTransportConnectors() - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
 
getTxTableName() - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getType() - Method in class org.codehaus.activemq.message.TransactionInfo
 
getType() - Method in class org.codehaus.activemq.message.XATransactionInfo
 
getType() - Method in class org.codehaus.activemq.transport.zeroconf.ZeroconfDiscoveryAgent
 
getUndeliveredMessages() - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueSubscription
 
getUnit() - Method in class org.codehaus.activemq.management.StatisticImpl
 
getUpdateDurableSubStatment() - Method in interface org.codehaus.activemq.store.jdbc.StatementProvider
 
getUpdateDurableSubStatment() - Method in class org.codehaus.activemq.store.jdbc.adapter.CachingStatementProvider
 
getUpdateDurableSubStatment() - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getUpdateLastAckOfDurableSub() - Method in interface org.codehaus.activemq.store.jdbc.StatementProvider
 
getUpdateLastAckOfDurableSub() - Method in class org.codehaus.activemq.store.jdbc.adapter.CachingStatementProvider
 
getUpdateLastAckOfDurableSub() - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getUpdateMessageStatment() - Method in interface org.codehaus.activemq.store.jdbc.StatementProvider
 
getUpdateMessageStatment() - Method in class org.codehaus.activemq.store.jdbc.adapter.CachingStatementProvider
 
getUpdateMessageStatment() - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getUpdateXidStatment() - Method in interface org.codehaus.activemq.store.jdbc.StatementProvider
 
getUpdateXidStatment() - Method in class org.codehaus.activemq.store.jdbc.adapter.CachingStatementProvider
 
getUpdateXidStatment() - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getUpperBound() - Method in class org.codehaus.activemq.management.BoundaryStatisticImpl
 
getUpperBound() - Method in class org.codehaus.activemq.management.BoundedRangeStatisticImpl
 
getUri() - Method in class org.codehaus.activemq.transport.NetworkChannel
 
getUri() - Method in class org.codehaus.activemq.util.JmsLogAppender
 
getUris() - Method in class org.codehaus.activemq.transport.composite.CompositeTransportChannel
 
getUrl() - Method in class org.codehaus.activemq.gbean.ActiveMQConnectorGBean
 
getUrl() - Method in interface org.codehaus.activemq.transport.TransportServerChannel
Returns the URL to connect to this connector
getUrl() - Method in class org.codehaus.activemq.transport.TransportServerChannelSupport
 
getUrlPkgPrefixes() - Method in class org.codehaus.activemq.util.JndiJmsLogAppender
 
getUseTime() - Method in class org.codehaus.activemq.management.JCAConnectionStatsImpl
 
getUserName() - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
 
getUserName() - Method in class org.codehaus.activemq.message.ConnectionInfo
 
getUserName() - Method in class org.codehaus.activemq.ra.ActiveMQConnectionRequestInfo
 
getUserName() - Method in class org.codehaus.activemq.ra.ActiveMQResourceAdapter
 
getUserName() - Method in class org.codehaus.activemq.util.JmsLogAppender
 
getUserName() - Method in class org.codehaus.activemq.util.JndiJmsLogAppender
 
getValueLimit() - Method in class org.codehaus.activemq.capacity.BasicCapacityMonitor
 
getValueLimit() - Method in interface org.codehaus.activemq.capacity.CapacityMonitor
 
getValueLimit() - Method in class org.codehaus.activemq.capacity.DelegateCapacityMonitor
 
getValues() - Method in class org.codehaus.activemq.filter.DestinationMapNode
Returns a mutable List of the values available at this node in the tree
getVersion() - Method in class org.codehaus.activemq.message.WireFormatInfo
 
getWaitTime() - Method in class org.codehaus.activemq.management.JCAConnectionStatsImpl
 
getWaitingThreadCount() - Method in class org.codehaus.activemq.management.JCAConnectionPoolStatsImpl
 
getWebClient(HttpServletRequest) - Method in class org.codehaus.activemq.web.MessageServletSupport
Helper method to get the client for the current session
getWebClient(HttpSession) - Static method in class org.codehaus.activemq.web.WebClient
 
getWeight() - Method in class org.codehaus.activemq.transport.zeroconf.ZeroconfDiscoveryAgent
 
getWireFormat() - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
 
getWireFormat() - Method in class org.codehaus.activemq.gbean.ActiveMQConnectorGBean
 
getWireFormat() - Method in class org.codehaus.activemq.store.bdb.BDbPersistenceAdapter
 
getWireFormat() - Method in class org.codehaus.activemq.store.jdbc.JDBCPersistenceAdapter
 
getWireFormat() - Method in class org.codehaus.activemq.store.journal.JournalPersistenceAdapter
 
getWireFormat() - Method in class org.codehaus.activemq.transport.http.HttpTransportChannelSupport
 
getWireFormat() - Method in class org.codehaus.activemq.transport.http.HttpTransportConnector
 
getWireFormatVersion() - Method in class org.codehaus.activemq.message.ConnectionInfo
 
getWritesPerSecond() - Method in class org.codehaus.activemq.journal.JournalStatsFilter
Gets the average number of writes done per second
getXAResource() - Method in class org.codehaus.activemq.ActiveMQXASession
 
getXAResource() - Method in class org.codehaus.activemq.ra.ActiveMQManagedConnection
 
getXAResources(ActivationSpec[]) - Method in class org.codehaus.activemq.ra.ActiveMQResourceAdapter
We only connect to one resource manager per ResourceAdapter instance, so any ActivationSpec will return the same XAResource.
getXATransaction(ActiveMQXid) - Method in interface org.codehaus.activemq.service.TransactionManager
 
getXATransaction(ActiveMQXid) - Method in class org.codehaus.activemq.service.impl.TransactionManagerImpl
 
getXStream() - Method in class org.codehaus.activemq.transport.xstream.XStreamWireFormat
 
getXid() - Method in class org.codehaus.activemq.message.XATransactionInfo
 
getXidDataType() - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
getXids() - Method in interface org.codehaus.activemq.store.PreparedTransactionStore
 
getXids() - Method in class org.codehaus.activemq.store.bdb.BDbPreparedTransactionStore
 
getXids() - Method in class org.codehaus.activemq.store.jdbc.JDBCPreparedTransactionStore
 
getXids() - Method in class org.codehaus.activemq.store.jdbm.JdbmPreparedTransactionStore
 
getXids() - Method in class org.codehaus.activemq.store.vm.VMPreparedTransactionStoreImpl
 
getXmppType(ActiveMQMessage) - Method in class org.codehaus.activemq.transport.jabber.JabberWireFormat
 
getXslResource() - Method in class org.codehaus.activemq.spring.ActiveMQBeanDefinitionReader
 

H

HASH_CHECKSUM_ALGORITHIM - Static variable in class org.codehaus.activemq.journal.impl.RecordFooter
 
HEAD_KEY - Static variable in class org.codehaus.activemq.service.impl.QueueListSupport
 
HowlJournal - class org.codehaus.activemq.journal.howl.HowlJournal.
An implementation of the Journal interface using a HOWL logger.
HowlJournal(Configuration) - Constructor for class org.codehaus.activemq.journal.howl.HowlJournal
 
HowlMessageStore - class org.codehaus.activemq.store.howl.HowlMessageStore.
An implementation of MessageStore designed for optimal use with Howl as the transaction log and then checkpointing asynchronously on a timeout with some other persistent storage.
HowlMessageStore(HowlPersistenceAdapter, MessageStore, Logger, WireFormat) - Constructor for class org.codehaus.activemq.store.howl.HowlMessageStore
 
HowlPersistenceAdapter - class org.codehaus.activemq.store.howl.HowlPersistenceAdapter.
An implementation of PersistenceAdapter designed for optimal use with Howl as the transaction log and then checkpointing asynchronously on a timeout with some other persistent storage.
HowlPersistenceAdapter() - Constructor for class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
HowlPersistenceAdapter(File, PersistenceAdapter) - Constructor for class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
HsqldbJDBCAdapter - class org.codehaus.activemq.store.jdbc.adapter.HsqldbJDBCAdapter.
 
HsqldbJDBCAdapter() - Constructor for class org.codehaus.activemq.store.jdbc.adapter.HsqldbJDBCAdapter
 
HsqldbJDBCAdapter(StatementProvider) - Constructor for class org.codehaus.activemq.store.jdbc.adapter.HsqldbJDBCAdapter
 
HsqldbJDBCAdapter.HSQLStatementProvider - class org.codehaus.activemq.store.jdbc.adapter.HsqldbJDBCAdapter.HSQLStatementProvider.
 
HsqldbJDBCAdapter.HSQLStatementProvider() - Constructor for class org.codehaus.activemq.store.jdbc.adapter.HsqldbJDBCAdapter.HSQLStatementProvider
 
HttpClientTransportChannel - class org.codehaus.activemq.transport.http.HttpClientTransportChannel.
A HTTP TransportChannel which uses the commons-httpclient library
HttpClientTransportChannel(TextWireFormat, String) - Constructor for class org.codehaus.activemq.transport.http.HttpClientTransportChannel
 
HttpServerTransportChannel - class org.codehaus.activemq.transport.http.HttpServerTransportChannel.
A server side HTTP based TransportChannel which processes incoming packets and adds outgoing packets onto a Channel so that they can be dispatched by the HTTP GET requests from the client.
HttpServerTransportChannel(Channel) - Constructor for class org.codehaus.activemq.transport.http.HttpServerTransportChannel
 
HttpTransportChannel - class org.codehaus.activemq.transport.http.HttpTransportChannel.
 
HttpTransportChannel(TextWireFormat, String) - Constructor for class org.codehaus.activemq.transport.http.HttpTransportChannel
 
HttpTransportChannelFactory - class org.codehaus.activemq.transport.http.HttpTransportChannelFactory.
 
HttpTransportChannelFactory() - Constructor for class org.codehaus.activemq.transport.http.HttpTransportChannelFactory
 
HttpTransportChannelSupport - class org.codehaus.activemq.transport.http.HttpTransportChannelSupport.
 
HttpTransportChannelSupport(TextWireFormat, String) - Constructor for class org.codehaus.activemq.transport.http.HttpTransportChannelSupport
 
HttpTransportConnector - class org.codehaus.activemq.transport.http.HttpTransportConnector.
 
HttpTransportConnector(URI) - Constructor for class org.codehaus.activemq.transport.http.HttpTransportConnector
 
HttpTransportConnectorFactory - class org.codehaus.activemq.transport.http.HttpTransportConnectorFactory.
 
HttpTransportConnectorFactory() - Constructor for class org.codehaus.activemq.transport.http.HttpTransportConnectorFactory
 
HttpTunnelServlet - class org.codehaus.activemq.transport.http.HttpTunnelServlet.
 
HttpTunnelServlet() - Constructor for class org.codehaus.activemq.transport.http.HttpTunnelServlet
 
handleAsyncException(JMSException) - Method in class org.codehaus.activemq.ActiveMQConnection
Used for handling async exceptions
handleException(ByteArrayServerClient, JMSException) - Method in class org.codehaus.activemq.transport.ember.EmberTransportServerChannel
 
hasActiveSubscribers() - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
 
hasCacheCapacity(HowlMessageStore) - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
Return true if a store is allowed to cache a message.
hasConsumerFor(ActiveMQDestination) - Method in class org.codehaus.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
 
hasConsumerFor(ActiveMQDestination) - Method in class org.codehaus.activemq.service.boundedvm.TransientTopicBoundedMessageManager
 
hasMoreElements() - Method in class org.codehaus.activemq.ActiveMQQueueBrowser
 
hasVisited(String) - Method in class org.codehaus.activemq.message.AbstractPacket
test to see if the named broker has already seen this packet
hasVisited(String) - Method in interface org.codehaus.activemq.message.Packet
test to see if the named broker has already seen this packet
hash(byte[], int) - Method in class org.codehaus.activemq.message.ActiveMQXid
 
hashCode() - Method in class org.codehaus.activemq.filter.BinaryExpression
TODO: more efficient hashCode()
hashCode() - Method in class org.codehaus.activemq.filter.ConstantExpression
TODO: more efficient hashCode()
hashCode() - Method in class org.codehaus.activemq.filter.MultiExpressionEvaluator.CacheExpression
 
hashCode() - Method in class org.codehaus.activemq.filter.PropertyExpression
 
hashCode() - Method in class org.codehaus.activemq.filter.UnaryExpression
TODO: more efficient hashCode()
hashCode() - Method in class org.codehaus.activemq.journal.howl.LongRecordLocation
 
hashCode() - Method in class org.codehaus.activemq.journal.impl.RecordLocationImpl
 
hashCode() - Method in class org.codehaus.activemq.journal.impl.Segment
 
hashCode() - Method in class org.codehaus.activemq.message.AbstractPacket
 
hashCode() - Method in class org.codehaus.activemq.message.ActiveMQDestination
 
hashCode() - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
hashCode() - Method in class org.codehaus.activemq.message.ActiveMQXid
 
hashCode() - Method in class org.codehaus.activemq.message.ConnectionInfo
 
hashCode() - Method in class org.codehaus.activemq.message.ConsumerInfo
 
hashCode() - Method in class org.codehaus.activemq.message.ProducerInfo
 
hashCode() - Method in class org.codehaus.activemq.message.SessionInfo
 
hashCode() - Method in class org.codehaus.activemq.message.TransactionInfo
 
hashCode() - Method in class org.codehaus.activemq.message.XATransactionInfo
 
hashCode() - Method in class org.codehaus.activemq.ra.ActiveMQConnectionRequestInfo
 
hashCode() - Method in class org.codehaus.activemq.ra.ActiveMQEndpointActivationKey
 
hashCode() - Method in class org.codehaus.activemq.service.MessageIdentity
 
hashCode() - Method in class org.codehaus.activemq.service.impl.MessageEntry
 
hashCode() - Method in class org.codehaus.activemq.transport.NetworkMessageBridge
 
headKey - Variable in class org.codehaus.activemq.service.impl.QueueListSupport.Header
 
header - Variable in class org.codehaus.activemq.journal.impl.Record
 
headerBuffer - Variable in class org.codehaus.activemq.journal.impl.Record
 
hostName - Variable in class org.codehaus.activemq.message.ConnectionInfo
 

I

ID - Static variable in interface org.codehaus.activemq.selector.SelectorParserConstants
 
IN - Static variable in interface org.codehaus.activemq.selector.SelectorParserConstants
 
INT - Static variable in class org.codehaus.activemq.message.ActiveMQMessage
 
INTEGER - Static variable in class org.codehaus.activemq.filter.ArithmeticExpression
 
INTEGER_LITERAL - Static variable in interface org.codehaus.activemq.selector.SelectorParserConstants
 
INT_RESPONSE_RECEIPT_INFO - Static variable in interface org.codehaus.activemq.message.Packet
A receipt with an Integer reponse.
INT_SIZE - Static variable in class org.codehaus.activemq.util.BitArray
 
INVALID_LEXICAL_STATE - Static variable in class org.codehaus.activemq.selector.TokenMgrError
Tried to change to an invalid lexical state.
IN_USE_STATE - Static variable in class org.codehaus.activemq.service.impl.AbstractTransaction
 
IS - Static variable in interface org.codehaus.activemq.selector.SelectorParserConstants
 
IdGenerator - class org.codehaus.activemq.util.IdGenerator.
Generator for globally unique Strings
IdGenerator() - Constructor for class org.codehaus.activemq.util.IdGenerator
Construct an IdGenerator
IndentPrinter - class org.codehaus.activemq.util.IndentPrinter.
A helper class for printing indented text
IndentPrinter() - Constructor for class org.codehaus.activemq.util.IndentPrinter
 
IndentPrinter(PrintWriter) - Constructor for class org.codehaus.activemq.util.IndentPrinter
 
IndentPrinter(PrintWriter, String) - Constructor for class org.codehaus.activemq.util.IndentPrinter
 
InitialImageMessageContainerManager - class org.codehaus.activemq.service.impl.InitialImageMessageContainerManager.
Implements an initial image service where on subscription the client will recieve the last image that was previously cached.
InitialImageMessageContainerManager(MessageContainerManager, Map, DestinationFilter) - Constructor for class org.codehaus.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.codehaus.activemq.service.impl.InitialImageMessageContainerManager
 
IntResponseReceipt - class org.codehaus.activemq.message.IntResponseReceipt.
A receipt that also carries a reponse object.
IntResponseReceipt() - Constructor for class org.codehaus.activemq.message.IntResponseReceipt
 
IntResponseReceiptReader - class org.codehaus.activemq.message.IntResponseReceiptReader.
Reads a ConsumerInfo object from a Stream
IntResponseReceiptReader() - Constructor for class org.codehaus.activemq.message.IntResponseReceiptReader
 
IntResponseReceiptWriter - class org.codehaus.activemq.message.IntResponseReceiptWriter.
Writes a ConsumerInfo object to a Stream
IntResponseReceiptWriter() - Constructor for class org.codehaus.activemq.message.IntResponseReceiptWriter
 
InvalidRecordLocationException - exception org.codehaus.activemq.journal.InvalidRecordLocationException.
Exception thrown by a Journal to indicate that an invalid RecordLocation was detected.
InvalidRecordLocationException() - Constructor for class org.codehaus.activemq.journal.InvalidRecordLocationException
 
InvalidRecordLocationException(String) - Constructor for class org.codehaus.activemq.journal.InvalidRecordLocationException
 
InvalidRecordLocationException(String, Throwable) - Constructor for class org.codehaus.activemq.journal.InvalidRecordLocationException
 
InvalidRecordLocationException(Throwable) - Constructor for class org.codehaus.activemq.journal.InvalidRecordLocationException
 
idleSessions - Variable in class org.codehaus.activemq.ra.ActiveMQAsfEndpointWorker.ServerSessionPoolImpl
 
image - Variable in class org.codehaus.activemq.selector.Token
The string image of the token.
increment() - Method in class org.codehaus.activemq.management.CountStatisticImpl
 
incrementIndent() - Method in class org.codehaus.activemq.util.IndentPrinter
 
incrementMemoryReferenceCount() - Method in class org.codehaus.activemq.message.AbstractPacket
Increment reference count for bounded memory collections
incrementMemoryReferenceCount() - Method in interface org.codehaus.activemq.message.Packet
Increment reference count for bounded memory collections
incrementMemoryUsed(Packet) - Method in class org.codehaus.activemq.message.util.MemoryBoundedQueueManager
 
incrementMessageCount(MessageIdentity) - Method in interface org.codehaus.activemq.store.TopicMessageStore
Increments the reference count of the message ID as its been dispatched to another subscriber.
incrementMessageCount(MessageIdentity) - Method in class org.codehaus.activemq.store.bdb.BDbTopicMessageStore
 
incrementMessageCount(MessageIdentity) - Method in class org.codehaus.activemq.store.bdbn.BDbTopicMessageStore
 
incrementMessageCount(MessageIdentity) - Method in class org.codehaus.activemq.store.cache.CacheTopicMessageStore
 
incrementMessageCount(MessageIdentity) - Method in class org.codehaus.activemq.store.jdbc.JDBCTopicMessageStore
 
incrementMessageCount(MessageIdentity) - Method in class org.codehaus.activemq.store.jdbm.JdbmTopicMessageStore
 
incrementMessageCount(MessageIdentity) - Method in class org.codehaus.activemq.store.vm.VMTopicMessageStore
 
incrementReferenceCount() - Method in class org.codehaus.activemq.transport.NetworkMessageBridge
increment number of references to this consumer
indexOf(Object) - Method in interface org.codehaus.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.
indexOf(Object) - Method in class org.codehaus.activemq.service.impl.DefaultQueueList
 
indexOf(Object) - Method in class org.codehaus.activemq.service.impl.QueueListSupport
 
inetAddress - Variable in class org.codehaus.activemq.transport.udp.UdpTransportChannel
 
init(SelectorManager, ThreadPool, ClockPool) - Static method in class org.codehaus.activemq.transport.gnet.GTransportChannelFactory
 
init(SelectorManager, ThreadPool, ClockPool) - Static method in class org.codehaus.activemq.transport.gnet.GTransportServerChannelFactory
 
init() - Method in class org.codehaus.activemq.transport.http.HttpTunnelServlet
 
init() - Method in class org.codehaus.activemq.web.MessageServlet
 
init(ServletConfig) - Method in class org.codehaus.activemq.web.MessageServletSupport
 
initConnectionFactory(ServletContext) - Static method in class org.codehaus.activemq.web.WebClient
 
initContext(ServletContext) - Static method in class org.codehaus.activemq.web.WebClient
 
initQueueConsumers(ServletContext) - Static method in class org.codehaus.activemq.web.WebClient
 
initSequenceGenerator(Connection) - Method in interface org.codehaus.activemq.store.jdbc.JDBCAdapter
 
initSequenceGenerator(Connection) - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
initialise(Map, PreparedTransactionStore) - Method in class org.codehaus.activemq.service.impl.XATransactionCommand
Called after the transaction command has been recovered from disk
initialise(SecondaryDatabase) - Method in class org.codehaus.activemq.store.bdb.SequenceNumberCreator
 
initialiseSocket() - Method in class org.codehaus.activemq.transport.tcp.TcpTransportChannel
Configures the socket for use
initialize(BrokerConnector, TransportChannel) - Method in interface org.codehaus.activemq.broker.BrokerClient
Initialize the Brokerclient
initialize(BrokerConnector, TransportChannel) - Method in class org.codehaus.activemq.broker.impl.BrokerClientImpl
Initialize the BrokerClient
initializeBrokersVisited() - Method in class org.codehaus.activemq.message.AbstractPacket
 
initializeOther(AbstractPacket) - Method in class org.codehaus.activemq.message.AbstractPacket
Initializes another message with current values from this instance
initializeOther(ActiveMQMessage) - Method in class org.codehaus.activemq.message.ActiveMQMessage
Initializes another message with current values from this instance
inspect(Destination) - Static method in class org.codehaus.activemq.message.ActiveMQDestination
A helper method to return a descriptive string for the topic or queue
internalBind(String, Object) - Method in class org.codehaus.activemq.jndi.ReadOnlyContext
internalBind is intended for use only during setup or possibly by suitably synchronized superclasses.
invalidate() - Method in class org.codehaus.activemq.journal.impl.RecordFooter
 
invalidate() - Method in class org.codehaus.activemq.journal.impl.RecordHeader
 
invoke(Object, Method, Object[]) - Method in class org.codehaus.activemq.util.AsyncProxy
 
isActive() - Method in class org.codehaus.activemq.journal.impl.Segment
 
isActive() - Method in interface org.codehaus.activemq.service.Subscription
 
isActive() - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
 
isAsyncSend() - Method in class org.codehaus.activemq.transport.vm.VmTransportChannel
 
isAtAppendOffset() - Method in class org.codehaus.activemq.journal.impl.Segment
 
isAtPrefetchLimit() - Method in interface org.codehaus.activemq.service.Subscription
Indicates the Subscription it's reached it's pre-fetch limit
isAtPrefetchLimit() - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
Indicates the Subscription it's reached it's pre-fetch limit
isBackOffMode() - Method in class org.codehaus.activemq.service.RedeliveryPolicy
Returns whether or not we use a back-off timeout (increasing the timeout by the RedeliveryPolicy.getBackOffIncreaseRate() each time).
isBrokerConnection() - Method in interface org.codehaus.activemq.broker.BrokerClient
 
isBrokerConnection() - Method in class org.codehaus.activemq.broker.impl.BrokerClientImpl
 
isBrowser() - Method in class org.codehaus.activemq.ActiveMQMessageConsumer
Retrive is a browser
isBrowser() - Method in class org.codehaus.activemq.message.ConsumerInfo
 
isBrowser() - Method in interface org.codehaus.activemq.service.Subscription
Indicates the consumer is a browser only
isBrowser() - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
Indicates the consumer is a browser only
isChangeTimeout() - Method in class org.codehaus.activemq.transport.tcp.TcpTransportChannel
 
isChecksumEnabled() - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
isChecksumingEnabled() - Static method in class org.codehaus.activemq.journal.impl.RecordFooter
 
isClientAcknowledge() - Method in class org.codehaus.activemq.ActiveMQSession
 
isClosed() - Method in class org.codehaus.activemq.message.ConnectionInfo
 
isClusteredConnection() - Method in interface org.codehaus.activemq.broker.BrokerClient
 
isClusteredConnection() - Method in class org.codehaus.activemq.broker.impl.BrokerClientImpl
 
isComposite() - Method in class org.codehaus.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.
isConsumerTarget(int) - Method in class org.codehaus.activemq.message.ActiveMQMessage
test to see if a particular Consumer at a Connection is meant to receive this Message
isDispatched() - Method in class org.codehaus.activemq.service.impl.MessagePointer
 
isDuplicate(Message) - Method in class org.codehaus.activemq.ActiveMQMessageAudit
Checks if this message has beeb seen before
isDuplicate(Packet) - Method in class org.codehaus.activemq.ActiveMQMessageAudit
checks whether this messageId has been seen before
isDuplicate(String) - Method in class org.codehaus.activemq.ActiveMQMessageAudit
checks whether this messageId has been seen before and adds this messageId to the list
isDurableSubscriber() - Method in class org.codehaus.activemq.ActiveMQMessageConsumer
 
isDurableTopic() - Method in class org.codehaus.activemq.message.ConsumerInfo
 
isDurableTopic() - Method in interface org.codehaus.activemq.service.Subscription
Indicates the Consumer is a Durable Subscriber
isDurableTopic() - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
Indicates the Subscriber is a Durable Subscriber
isDurableTopic() - Method in class org.codehaus.activemq.transport.NetworkMessageBridge
 
isEmpty() - Method in interface org.codehaus.activemq.message.util.BoundedPacketQueue
 
isEmpty() - Method in class org.codehaus.activemq.message.util.DataContainer
 
isEmpty() - Method in class org.codehaus.activemq.message.util.MemoryBoundedQueue
 
isEmpty() - Method in class org.codehaus.activemq.message.util.SpooledBoundedPacketQueue
 
isEmpty() - Method in interface org.codehaus.activemq.service.QueueList
is the list empty?
isEmpty() - Method in class org.codehaus.activemq.service.impl.DefaultQueueList
 
isEmpty() - Method in class org.codehaus.activemq.service.impl.QueueListSupport
 
isEnoughSpace(byte[]) - Method in class org.codehaus.activemq.message.util.FileDataBlock
test to if there is enough room in the block to write the data
isEntryBroker(String) - Method in class org.codehaus.activemq.message.ActiveMQMessage
Determine if the message originated in the network from the named broker
isEntryCluster(String) - Method in class org.codehaus.activemq.message.ActiveMQMessage
Determine if the message originated in the network from the named cluster
isExpired(long) - Method in class org.codehaus.activemq.message.ActiveMQMessage
Indicates if the Message has expired
isExpired() - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
isFailed() - Method in class org.codehaus.activemq.message.Receipt
 
isFrozen() - Method in class org.codehaus.activemq.jndi.ReadOnlyContext
 
isFull() - Method in class org.codehaus.activemq.message.util.MemoryBoundedQueueManager
 
isFull() - Method in class org.codehaus.activemq.message.util.SpooledBoundedPacketQueue
 
isInactive() - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
 
isInactive() - Method in class org.codehaus.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
 
isJMSMessage() - Method in class org.codehaus.activemq.message.AbstractPacket
Retrieve if a JMS Message type or not
isJMSMessage() - Method in class org.codehaus.activemq.message.ActiveMQMessage
Retrieve if a JMS Message type or not
isJMSMessage() - Method in interface org.codehaus.activemq.message.Packet
Retrieve if a JMS Message type or not
isMaintainDestinationStats() - Method in class org.codehaus.activemq.service.impl.MessageContainerManagerSupport
 
isMatchingConnectionFactory(ConnectionFactory, JMSURLHelper, HashMap) - Method in class org.codehaus.activemq.axis.ActiveMQVendorAdapter
 
isMessageConsumed() - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
isMessageRead() - Method in class org.codehaus.activemq.message.MessageAck
 
isMulticast() - Method in interface org.codehaus.activemq.transport.TransportChannel
 
isMulticast() - Method in class org.codehaus.activemq.transport.composite.CompositeTransportChannel
 
isMulticast() - Method in class org.codehaus.activemq.transport.ember.EmberTransportChannel
 
isMulticast() - Method in class org.codehaus.activemq.transport.gnet.GTransportChannel
 
isMulticast() - Method in class org.codehaus.activemq.transport.http.HttpClientTransportChannel
 
isMulticast() - Method in class org.codehaus.activemq.transport.http.HttpServerTransportChannel
 
isMulticast() - Method in class org.codehaus.activemq.transport.http.HttpTransportChannel
 
isMulticast() - Method in class org.codehaus.activemq.transport.http.HttpTransportChannelSupport
 
isMulticast() - Method in class org.codehaus.activemq.transport.jgroups.JGroupsTransportChannel
 
isMulticast() - Method in class org.codehaus.activemq.transport.jrms.JRMSTransportChannel
 
isMulticast() - Method in class org.codehaus.activemq.transport.multicast.MulticastTransportChannel
 
isMulticast() - Method in class org.codehaus.activemq.transport.tcp.TcpTransportChannel
 
isMulticast() - Method in class org.codehaus.activemq.transport.udp.UdpTransportChannel
 
isMulticast() - Method in class org.codehaus.activemq.transport.vm.VmTransportChannel
 
isNoLocal() - Method in class org.codehaus.activemq.ActiveMQMessageConsumer
 
isNoLocal() - Method in class org.codehaus.activemq.message.ConsumerInfo
 
isNoLocal() - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
 
isPartOfTransaction() - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
isPartOfTransaction() - Method in class org.codehaus.activemq.message.MessageAck
 
isPendingStop() - Method in interface org.codehaus.activemq.transport.TransportChannel
 
isPendingStop() - Method in class org.codehaus.activemq.transport.TransportChannelSupport
 
isPersistent() - Method in class org.codehaus.activemq.message.MessageAck
 
isQueue() - Method in class org.codehaus.activemq.message.ActiveMQDestination
Returns true if a Queue Destination
isRead() - Method in class org.codehaus.activemq.service.impl.MessagePointer
 
isReadOnly() - Method in class org.codehaus.activemq.journal.impl.Segment
 
isReadyToDispatch() - Method in interface org.codehaus.activemq.service.Subscription
Indicates if this Subscription has more messages to send to the Consumer
isReadyToDispatch() - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
Indicates if this Subscription has more messages to send to the Consumer
isReceipt() - Method in class org.codehaus.activemq.message.AbstractPacket
 
isReceipt() - Method in interface org.codehaus.activemq.message.Packet
 
isReceipt() - Method in class org.codehaus.activemq.message.Receipt
 
isReceiptRequired() - Method in class org.codehaus.activemq.message.AbstractPacket
 
isReceiptRequired() - Method in interface org.codehaus.activemq.message.Packet
 
isRedelivered() - Method in class org.codehaus.activemq.service.impl.MessagePointer
 
isResuseMessageId() - Method in class org.codehaus.activemq.ActiveMQMessageProducer
 
isSameDurableSubscription(ConsumerInfo) - Method in interface org.codehaus.activemq.service.Subscription
Checks if this subscription is a duplicate durable subscription of the given consumer info
isSameDurableSubscription(ConsumerInfo) - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
 
isSameRM(XAResource) - Method in class org.codehaus.activemq.ActiveMQXASession
 
isSegmentIndexActive(byte) - Method in class org.codehaus.activemq.journal.impl.LogFile
 
isServerSide() - Method in interface org.codehaus.activemq.transport.TransportChannel
 
isServerSide() - Method in class org.codehaus.activemq.transport.TransportChannelSupport
 
isSlowConsumer() - Method in interface org.codehaus.activemq.broker.BrokerClient
Get an indication if the peer should be considered as a slow consumer
isSlowConsumer() - Method in class org.codehaus.activemq.broker.impl.BrokerClientImpl
Get an indication if the peer should be considered as a slow consumer
isStarted() - Method in class org.codehaus.activemq.ActiveMQConnection
 
isStarted() - Method in class org.codehaus.activemq.message.ConnectionInfo
 
isStarted() - Method in class org.codehaus.activemq.message.ConsumerInfo
 
isStarted() - Method in class org.codehaus.activemq.message.ProducerInfo
 
isStarted() - Method in class org.codehaus.activemq.message.SessionInfo
 
isStarted() - Method in interface org.codehaus.activemq.message.util.BoundedPacketQueue
 
isStarted() - Method in class org.codehaus.activemq.message.util.MemoryBoundedQueue
 
isStarted() - Method in class org.codehaus.activemq.message.util.SpooledBoundedPacketQueue
 
isSync() - Method in class org.codehaus.activemq.store.journal.JournalPersistenceAdapter
 
isTarget(ActiveMQMessage) - Method in class org.codehaus.activemq.ActiveMQConnectionConsumer
Tests to see if the Message Dispatcher is a target for this message
isTarget(ActiveMQMessage) - Method in interface org.codehaus.activemq.ActiveMQMessageDispatcher
Tests to see if the Message Dispatcher is a target for this message
isTarget(ActiveMQMessage) - Method in class org.codehaus.activemq.ActiveMQSession
Tests to see if the Message Dispatcher is a target for this message
isTarget(ActiveMQMessage) - Method in interface org.codehaus.activemq.service.Subscription
determines if the Subscription is interested in the message
isTarget(ActiveMQMessage) - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueSubscription
determines if the Subscription is interested in the message
isTarget(ActiveMQMessage) - Method in class org.codehaus.activemq.service.boundedvm.TransientSubscription
determines if the Subscription is interested in the message
isTarget(ActiveMQMessage) - Method in class org.codehaus.activemq.service.boundedvm.TransientTopicSubscription
determines if the Subscription is interested in the message
isTarget(ActiveMQMessage) - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
determines if the Subscription is interested in the message
isTemporary() - Method in class org.codehaus.activemq.message.ActiveMQDestination
Returns true if a temporary Destination
isTemporary() - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
isTemporary() - Method in class org.codehaus.activemq.message.MessageAck
 
isTopic() - Method in class org.codehaus.activemq.message.ActiveMQDestination
Returns true if a Topic Destination
isTopic(HttpServletRequest) - Method in class org.codehaus.activemq.web.MessageServletSupport
 
isTransacted() - Method in class org.codehaus.activemq.ActiveMQSession
 
isTransactional() - Method in class org.codehaus.activemq.management.JMSConnectionStatsImpl
 
isTransientConsumed() - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
isTransportConnected() - Method in interface org.codehaus.activemq.transport.TransportChannel
 
isTransportConnected() - Method in class org.codehaus.activemq.transport.TransportChannelSupport
 
isUseAsyncSend() - Method in class org.codehaus.activemq.ActiveMQConnection
 
isUseAsyncSend() - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
 
isUseAsyncSend() - Method in class org.codehaus.activemq.transport.tcp.TcpTransportChannel
 
isUseAsyncSend() - Method in class org.codehaus.activemq.transport.tcp.TcpTransportServerChannel
 
isUseEmbeddedBroker() - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
Is an embedded broker used by this connection factory
isValid() - Method in class org.codehaus.activemq.journal.impl.RecordHeader
 
isValid(ActiveMQDestination) - Method in class org.codehaus.activemq.service.impl.InitialImageMessageContainerManager
Does this message match the destinations on which initial image caching should be used
isWildcard() - Method in class org.codehaus.activemq.filter.AndFilter
 
isWildcard() - Method in class org.codehaus.activemq.filter.CompositeDestinationFilter
 
isWildcard() - Method in class org.codehaus.activemq.filter.ExpressionFilter
 
isWildcard() - Method in interface org.codehaus.activemq.filter.Filter
 
isWildcard() - Method in class org.codehaus.activemq.filter.NoLocalFilter
 
isWildcard() - Method in class org.codehaus.activemq.filter.NotFilter
 
isWildcard() - Method in class org.codehaus.activemq.filter.OrFilter
 
isWildcard() - Method in class org.codehaus.activemq.filter.PrefixDestinationFilter
 
isWildcard() - Method in class org.codehaus.activemq.filter.SimpleDestinationFilter
 
isWildcard() - Method in class org.codehaus.activemq.filter.WildcardDestinationFilter
 
isWildcard() - Method in class org.codehaus.activemq.message.ActiveMQDestination
 
isWildcard() - Method in interface org.codehaus.activemq.service.Subscription
 
isWildcard() - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
 
isXA() - Method in class org.codehaus.activemq.ra.ActiveMQResourceAdapter
 
isXa() - Method in class org.codehaus.activemq.ra.ActiveMQConnectionRequestInfo
 
isXaTransacted() - Method in class org.codehaus.activemq.ActiveMQSession
 
isXaTransacted() - Method in class org.codehaus.activemq.ActiveMQXASession
 
isXaTransacted() - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
isXaTransacted() - Method in class org.codehaus.activemq.message.MessageAck
 
itemExists(String) - Method in class org.codehaus.activemq.message.ActiveMQMapMessage
Indicates whether an item exists in this MapMessage object.

J

JCAConnectionPoolStatsImpl - class org.codehaus.activemq.management.JCAConnectionPoolStatsImpl.
Statistics for a JCA connection pool
JCAConnectionPoolStatsImpl(String, String, TimeStatistic, TimeStatistic, CountStatistic, CountStatistic, BoundedRangeStatistic, BoundedRangeStatistic, RangeStatistic) - Constructor for class org.codehaus.activemq.management.JCAConnectionPoolStatsImpl
 
JCAConnectionStatsImpl - class org.codehaus.activemq.management.JCAConnectionStatsImpl.
Statistics for a JCA connection
JCAConnectionStatsImpl(String, String, TimeStatistic, TimeStatistic) - Constructor for class org.codehaus.activemq.management.JCAConnectionStatsImpl
 
JCAStatsImpl - class org.codehaus.activemq.management.JCAStatsImpl.
Statistics for a number of JCA connections and connection pools
JCAStatsImpl(JCAConnectionStats[], JCAConnectionPoolStats[]) - Constructor for class org.codehaus.activemq.management.JCAStatsImpl
 
JDBCAdapter - interface org.codehaus.activemq.store.jdbc.JDBCAdapter.
 
JDBCAdapter.MessageListResultHandler - interface org.codehaus.activemq.store.jdbc.JDBCAdapter.MessageListResultHandler.
 
JDBCMessageStore - class org.codehaus.activemq.store.jdbc.JDBCMessageStore.
 
JDBCMessageStore(JDBCPersistenceAdapter, JDBCAdapter, WireFormat, String) - Constructor for class org.codehaus.activemq.store.jdbc.JDBCMessageStore
 
JDBCPersistenceAdapter - class org.codehaus.activemq.store.jdbc.JDBCPersistenceAdapter.
A PersistenceAdapter implementation using JDBC for persistence storage.
JDBCPersistenceAdapter() - Constructor for class org.codehaus.activemq.store.jdbc.JDBCPersistenceAdapter
 
JDBCPersistenceAdapter(DataSource, WireFormat) - Constructor for class org.codehaus.activemq.store.jdbc.JDBCPersistenceAdapter
 
JDBCPreparedTransactionStore - class org.codehaus.activemq.store.jdbc.JDBCPreparedTransactionStore.
 
JDBCPreparedTransactionStore(JDBCPersistenceAdapter, JDBCAdapter, WireFormat) - Constructor for class org.codehaus.activemq.store.jdbc.JDBCPreparedTransactionStore
 
JDBCTopicMessageStore - class org.codehaus.activemq.store.jdbc.JDBCTopicMessageStore.
 
JDBCTopicMessageStore(JDBCPersistenceAdapter, JDBCAdapter, WireFormat, String) - Constructor for class org.codehaus.activemq.store.jdbc.JDBCTopicMessageStore
 
JGroupsTransportChannel - class org.codehaus.activemq.transport.jgroups.JGroupsTransportChannel.
A JGroups implementation of a TransportChannel
JGroupsTransportChannel(WireFormat, Channel, Executor) - Constructor for class org.codehaus.activemq.transport.jgroups.JGroupsTransportChannel
 
JGroupsTransportChannelFactory - class org.codehaus.activemq.transport.jgroups.JGroupsTransportChannelFactory.
A JGroups implementation of a TransportChannelFactory
JGroupsTransportChannelFactory() - Constructor for class org.codehaus.activemq.transport.jgroups.JGroupsTransportChannelFactory
 
JGroupsTransportChannelFactory(ChannelFactory, Object, String) - Constructor for class org.codehaus.activemq.transport.jgroups.JGroupsTransportChannelFactory
 
JGroupsTransportServerChannel - class org.codehaus.activemq.transport.jgroups.JGroupsTransportServerChannel.
A JGroups implementation of TransportServerChannel
JGroupsTransportServerChannel(URI) - Constructor for class org.codehaus.activemq.transport.jgroups.JGroupsTransportServerChannel
 
JGroupsTransportServerChannelFactory - class org.codehaus.activemq.transport.jgroups.JGroupsTransportServerChannelFactory.
A JGroups implementation of a TransportServerChannelFactory
JGroupsTransportServerChannelFactory() - Constructor for class org.codehaus.activemq.transport.jgroups.JGroupsTransportServerChannelFactory
 
JMSConnectionProxy - class org.codehaus.activemq.ra.JMSConnectionProxy.
Acts as a pass through proxy for a JMS Connection object.
JMSConnectionProxy(ActiveMQManagedConnection) - Constructor for class org.codehaus.activemq.ra.JMSConnectionProxy
 
JMSConnectionStatsImpl - class org.codehaus.activemq.management.JMSConnectionStatsImpl.
Statistics for a JMS connection
JMSConnectionStatsImpl(List, boolean) - Constructor for class org.codehaus.activemq.management.JMSConnectionStatsImpl
 
JMSConsumerStatsImpl - class org.codehaus.activemq.management.JMSConsumerStatsImpl.
Statistics for a JMS consumer
JMSConsumerStatsImpl(JMSSessionStatsImpl, Destination) - Constructor for class org.codehaus.activemq.management.JMSConsumerStatsImpl
 
JMSConsumerStatsImpl(CountStatisticImpl, CountStatisticImpl, CountStatisticImpl, TimeStatisticImpl, TimeStatisticImpl, String) - Constructor for class org.codehaus.activemq.management.JMSConsumerStatsImpl
 
JMSDestinationStats - interface org.codehaus.activemq.management.JMSDestinationStats.
A simple interface to allow statistics gathering to be easily switched out for performance reasons.
JMSEndpointStatsImpl - class org.codehaus.activemq.management.JMSEndpointStatsImpl.
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.codehaus.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.codehaus.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.codehaus.activemq.management.JMSEndpointStatsImpl
 
JMSExceptionHelper - class org.codehaus.activemq.util.JMSExceptionHelper.
A helper class for creating new JMS exceptions
JMSExceptionHelper() - Constructor for class org.codehaus.activemq.util.JMSExceptionHelper
 
JMSProducerStatsImpl - class org.codehaus.activemq.management.JMSProducerStatsImpl.
Statistics for a JMS producer
JMSProducerStatsImpl(JMSSessionStatsImpl, Destination) - Constructor for class org.codehaus.activemq.management.JMSProducerStatsImpl
 
JMSProducerStatsImpl(CountStatisticImpl, CountStatisticImpl, CountStatisticImpl, TimeStatisticImpl, TimeStatisticImpl, String) - Constructor for class org.codehaus.activemq.management.JMSProducerStatsImpl
 
JMSQueueStatsImpl - class org.codehaus.activemq.management.JMSQueueStatsImpl.
Statistics for a Queue
JMSQueueStatsImpl() - Constructor for class org.codehaus.activemq.management.JMSQueueStatsImpl
 
JMSQueueStatsImpl(CountStatisticImpl, CountStatisticImpl, CountStatisticImpl, TimeStatisticImpl, TimeStatisticImpl, TimeStatisticImpl) - Constructor for class org.codehaus.activemq.management.JMSQueueStatsImpl
 
JMSSessionProxy - class org.codehaus.activemq.ra.JMSSessionProxy.
Acts as a pass through proxy for a JMS Session object.
JMSSessionProxy(ActiveMQManagedConnection) - Constructor for class org.codehaus.activemq.ra.JMSSessionProxy
 
JMSSessionStatsImpl - class org.codehaus.activemq.management.JMSSessionStatsImpl.
Statistics for a JMS session
JMSSessionStatsImpl(List, List) - Constructor for class org.codehaus.activemq.management.JMSSessionStatsImpl
 
JMSStatsImpl - class org.codehaus.activemq.management.JMSStatsImpl.
Statistics for a number of JMS connections
JMSStatsImpl() - Constructor for class org.codehaus.activemq.management.JMSStatsImpl
 
JMSTopicStatsImpl - class org.codehaus.activemq.management.JMSTopicStatsImpl.
Statistics for a Topic
JMSTopicStatsImpl() - Constructor for class org.codehaus.activemq.management.JMSTopicStatsImpl
 
JMS_PUBLISH_ERROR_CODE - Static variable in class org.codehaus.activemq.util.JmsLogAppenderSupport
 
JNDIBaseStorable - class org.codehaus.activemq.jndi.JNDIBaseStorable.
Faciliates objects to be stored in JNDI as properties
JNDIBaseStorable() - Constructor for class org.codehaus.activemq.jndi.JNDIBaseStorable
 
JNDIReferenceFactory - class org.codehaus.activemq.jndi.JNDIReferenceFactory.
Converts objects implementing JNDIStorable into a property fields so they can be stored and regenerated from JNDI
JNDIReferenceFactory() - Constructor for class org.codehaus.activemq.jndi.JNDIReferenceFactory
 
JNDIStorableInterface - interface org.codehaus.activemq.jndi.JNDIStorableInterface.
Faciliates objects to be stored in JNDI as properties
JOIN - Static variable in interface org.codehaus.activemq.message.TransactionType
Join a transaction
JRMSTransportChannel - class org.codehaus.activemq.transport.jrms.JRMSTransportChannel.
A JRMS implementation of a TransportChannel
JRMSTransportChannel(WireFormat) - Constructor for class org.codehaus.activemq.transport.jrms.JRMSTransportChannel
Construct basic helpers
JRMSTransportChannel(WireFormat, URI) - Constructor for class org.codehaus.activemq.transport.jrms.JRMSTransportChannel
Connect to a remote Node - e.g.
JRMSTransportChannelFactory - class org.codehaus.activemq.transport.jrms.JRMSTransportChannelFactory.
A JRMS implementation of a TransportChannelFactory
JRMSTransportChannelFactory() - Constructor for class org.codehaus.activemq.transport.jrms.JRMSTransportChannelFactory
 
JRMSTransportServerChannel - class org.codehaus.activemq.transport.jrms.JRMSTransportServerChannel.
A JRMS implementation of TransportServerChannel
JRMSTransportServerChannel(WireFormat, URI) - Constructor for class org.codehaus.activemq.transport.jrms.JRMSTransportServerChannel
 
JRMSTransportServerChannelFactory - class org.codehaus.activemq.transport.jrms.JRMSTransportServerChannelFactory.
A multicast implementation of a TransportServerChannelFactory
JRMSTransportServerChannelFactory() - Constructor for class org.codehaus.activemq.transport.jrms.JRMSTransportServerChannelFactory
 
JabberWireFormat - class org.codehaus.activemq.transport.jabber.JabberWireFormat.
A wire format which uses XMPP format of messages
JabberWireFormat() - Constructor for class org.codehaus.activemq.transport.jabber.JabberWireFormat
 
JdbmMessageStore - class org.codehaus.activemq.store.jdbm.JdbmMessageStore.
 
JdbmMessageStore(BTree, BTree) - Constructor for class org.codehaus.activemq.store.jdbm.JdbmMessageStore
 
JdbmPersistenceAdapter - class org.codehaus.activemq.store.jdbm.JdbmPersistenceAdapter.
A PersistenceAdapter implementation for JDBM
JdbmPersistenceAdapter() - Constructor for class org.codehaus.activemq.store.jdbm.JdbmPersistenceAdapter
 
JdbmPersistenceAdapter(File) - Constructor for class org.codehaus.activemq.store.jdbm.JdbmPersistenceAdapter
 
JdbmPersistenceAdapter(RecordManager) - Constructor for class org.codehaus.activemq.store.jdbm.JdbmPersistenceAdapter
 
JdbmPreparedTransactionStore - class org.codehaus.activemq.store.jdbm.JdbmPreparedTransactionStore.
 
JdbmPreparedTransactionStore(BTree) - Constructor for class org.codehaus.activemq.store.jdbm.JdbmPreparedTransactionStore
 
JdbmTopicMessageStore - class org.codehaus.activemq.store.jdbm.JdbmTopicMessageStore.
 
JdbmTopicMessageStore(BTree, BTree, BTree, BTree, BTree) - Constructor for class org.codehaus.activemq.store.jdbm.JdbmTopicMessageStore
 
JmsLogAppender - class org.codehaus.activemq.util.JmsLogAppender.
A JMS 1.1 log4j appender which uses ActiveMQ by default and does not require any JNDI configurations
JmsLogAppender() - Constructor for class org.codehaus.activemq.util.JmsLogAppender
 
JmsLogAppenderSupport - class org.codehaus.activemq.util.JmsLogAppenderSupport.
An abstract base class for implementation inheritence for a log4j JMS appender
JmsLogAppenderSupport() - Constructor for class org.codehaus.activemq.util.JmsLogAppenderSupport
 
JmsSelector() - Method in class org.codehaus.activemq.selector.SelectorParser
 
JndiJmsLogAppender - class org.codehaus.activemq.util.JndiJmsLogAppender.
A JMS 1.1 log4j appender which uses JNDI to locate a JMS ConnectionFactory to use for logging events.
JndiJmsLogAppender() - Constructor for class org.codehaus.activemq.util.JndiJmsLogAppender
 
Journal - interface org.codehaus.activemq.journal.Journal.
A Journal is a record logging Interface that can be used to implement a transaction log.
JournalEventListener - interface org.codehaus.activemq.journal.JournalEventListener.
Defines an object which listens for Journal Events.
JournalImpl - class org.codehaus.activemq.journal.impl.JournalImpl.
A high speed Journal implementation.
JournalImpl() - Constructor for class org.codehaus.activemq.journal.impl.JournalImpl
 
JournalImpl(File) - Constructor for class org.codehaus.activemq.journal.impl.JournalImpl
 
JournalImpl(File, int, int) - Constructor for class org.codehaus.activemq.journal.impl.JournalImpl
 
JournalMessageStore - class org.codehaus.activemq.store.journal.JournalMessageStore.
A MessageStore that uses a Journal to store it's messages.
JournalMessageStore(JournalPersistenceAdapter, MessageStore, String, boolean) - Constructor for class org.codehaus.activemq.store.journal.JournalMessageStore
 
JournalPersistenceAdapter - class org.codehaus.activemq.store.journal.JournalPersistenceAdapter.
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.codehaus.activemq.store.journal.JournalPersistenceAdapter
 
JournalPersistenceAdapter(File, PersistenceAdapter, DefaultWireFormat) - Constructor for class org.codehaus.activemq.store.journal.JournalPersistenceAdapter
 
JournalStatsFilter - class org.codehaus.activemq.journal.JournalStatsFilter.
A Journal filter that captures performance statistics of the filtered Journal.
JournalStatsFilter(Journal) - Constructor for class org.codehaus.activemq.journal.JournalStatsFilter
Creates a JournalStatsFilter that captures performance information of next.
JxtaTransportChannel - class org.codehaus.activemq.transport.jxta.JxtaTransportChannel.
A JXTA implementation of a TransportChannel
JxtaTransportChannel(WireFormat, URI) - Constructor for class org.codehaus.activemq.transport.jxta.JxtaTransportChannel
Connect to a remote Node - e.g.
JxtaTransportChannel(WireFormat, URI, URI) - Constructor for class org.codehaus.activemq.transport.jxta.JxtaTransportChannel
Connect to a remote Node - e.g.
JxtaTransportChannelFactory - class org.codehaus.activemq.transport.jxta.JxtaTransportChannelFactory.
A JXTA implementation of a TransportChannelFactory
JxtaTransportChannelFactory() - Constructor for class org.codehaus.activemq.transport.jxta.JxtaTransportChannelFactory
 
JxtaTransportServerChannel - class org.codehaus.activemq.transport.jxta.JxtaTransportServerChannel.
Binds to a well known port and listens for Sockets ...
JxtaTransportServerChannel(WireFormat, URI) - Constructor for class org.codehaus.activemq.transport.jxta.JxtaTransportServerChannel
Default Constructor
JxtaTransportServerChannelFactory - class org.codehaus.activemq.transport.jxta.JxtaTransportServerChannelFactory.
A JXTA implementation of a TransportServerChannelFactory
JxtaTransportServerChannelFactory() - Constructor for class org.codehaus.activemq.transport.jxta.JxtaTransportServerChannelFactory
 
jj_input_stream - Variable in class org.codehaus.activemq.selector.SelectorParser
 
jj_nt - Variable in class org.codehaus.activemq.selector.SelectorParser
 
jjbitVec0 - Static variable in class org.codehaus.activemq.selector.SelectorParserTokenManager
 
jjbitVec2 - Static variable in class org.codehaus.activemq.selector.SelectorParserTokenManager
 
jjmatchedKind - Variable in class org.codehaus.activemq.selector.SelectorParserTokenManager
 
jjmatchedPos - Variable in class org.codehaus.activemq.selector.SelectorParserTokenManager
 
jjnewStateCnt - Variable in class org.codehaus.activemq.selector.SelectorParserTokenManager
 
jjnextStates - Static variable in class org.codehaus.activemq.selector.SelectorParserTokenManager
 
jjround - Variable in class org.codehaus.activemq.selector.SelectorParserTokenManager
 
jjstrLiteralImages - Static variable in class org.codehaus.activemq.selector.SelectorParserTokenManager
 
jjtoSkip - Static variable in class org.codehaus.activemq.selector.SelectorParserTokenManager
 
jjtoSpecial - Static variable in class org.codehaus.activemq.selector.SelectorParserTokenManager
 
jjtoToken - Static variable in class org.codehaus.activemq.selector.SelectorParserTokenManager
 

K

keepAlivePing(HttpServerTransportChannel) - Method in class org.codehaus.activemq.transport.http.HttpTunnelServlet
Disable this channel from being auto-disconnected after a timeout period
key - Variable in class org.codehaus.activemq.service.impl.QueueListSupport.Node
 
kind - Variable in class org.codehaus.activemq.selector.Token
An integer that describes the kind of this token.

L

LEXICAL_ERROR - Static variable in class org.codehaus.activemq.selector.TokenMgrError
Lexical error occured.
LIKE - Static variable in interface org.codehaus.activemq.selector.SelectorParserConstants
 
LINE_COMMENT - Static variable in interface org.codehaus.activemq.selector.SelectorParserConstants
 
LONG - Static variable in class org.codehaus.activemq.filter.ArithmeticExpression
 
LONG - Static variable in class org.codehaus.activemq.message.ActiveMQMessage
 
LONG_SIZE - Static variable in class org.codehaus.activemq.util.BitArray
 
LOOP_DETECTED - Static variable in class org.codehaus.activemq.selector.TokenMgrError
Detected (and bailed out of) an infinite loop in the token manager.
LRUCache - class org.codehaus.activemq.util.LRUCache.
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.codehaus.activemq.util.LRUCache
 
LRUCache(int) - Constructor for class org.codehaus.activemq.util.LRUCache
 
LRUCache(int, boolean) - Constructor for class org.codehaus.activemq.util.LRUCache
 
LocalTransactionCommand - class org.codehaus.activemq.service.impl.LocalTransactionCommand.
 
LocalTransactionCommand(Broker, Map, Object) - Constructor for class org.codehaus.activemq.service.impl.LocalTransactionCommand
 
LocalTransactionEventListener - interface org.codehaus.activemq.ra.LocalTransactionEventListener.
 
LogFile - class org.codehaus.activemq.journal.impl.LogFile.
Provides a logical view of many seperate files as one single long log file.
LogFile(File) - Constructor for class org.codehaus.activemq.journal.impl.LogFile
 
LogFile(File, int, int) - Constructor for class org.codehaus.activemq.journal.impl.LogFile
 
LogFile.RecordInfo - class org.codehaus.activemq.journal.impl.LogFile.RecordInfo.
 
LogFile.RecordInfo(RecordLocationImpl, RecordHeader) - Constructor for class org.codehaus.activemq.journal.impl.LogFile.RecordInfo
 
LogFileManager - class org.codehaus.activemq.journal.impl.LogFileManager.
The LogFileManager manages concurent access to a LogFile.
LogFileManager(byte, LongSequenceGenerator, File) - Constructor for class org.codehaus.activemq.journal.impl.LogFileManager
 
LogFileManager(byte, LongSequenceGenerator, LogFile) - Constructor for class org.codehaus.activemq.journal.impl.LogFileManager
 
LogicExpression - class org.codehaus.activemq.filter.LogicExpression.
A filter performing a comparison of two objects
LogicExpression(BooleanExpression, BooleanExpression) - Constructor for class org.codehaus.activemq.filter.LogicExpression
 
LongRecordLocation - class org.codehaus.activemq.journal.howl.LongRecordLocation.
Provides a RecordLocation implementation for the long based location pointers that HOWL uses.
LongRecordLocation(long) - Constructor for class org.codehaus.activemq.journal.howl.LongRecordLocation
 
LongSequenceGenerator - class org.codehaus.activemq.util.LongSequenceGenerator.
Generates sequence ids used to identify messages in the SQL tables.
LongSequenceGenerator() - Constructor for class org.codehaus.activemq.util.LongSequenceGenerator
 
lastIndexOf(Object) - Method in interface org.codehaus.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.
lastIndexOf(Object) - Method in class org.codehaus.activemq.service.impl.DefaultQueueList
 
lastIndexOf(Object) - Method in class org.codehaus.activemq.service.impl.QueueListSupport
 
lastKeyValue - Variable in class org.codehaus.activemq.service.impl.QueueListSupport.Header
 
lastSequenceId - Variable in class org.codehaus.activemq.util.LongSequenceGenerator
 
left - Variable in class org.codehaus.activemq.filter.BinaryExpression
 
length - Variable in class org.codehaus.activemq.journal.impl.RecordHeader
 
length() - Method in class org.codehaus.activemq.message.util.DataContainer
 
length() - Method in class org.codehaus.activemq.util.BitArray
 
lexStateNames - Static variable in class org.codehaus.activemq.selector.SelectorParserTokenManager
 
likePattern - Variable in class org.codehaus.activemq.filter.ComparisonExpression.LikeExpression
 
list(String) - Method in class org.codehaus.activemq.jndi.ReadOnlyContext
 
list(Name) - Method in class org.codehaus.activemq.jndi.ReadOnlyContext
 
listBindings(String) - Method in class org.codehaus.activemq.jndi.ReadOnlyContext
 
listBindings(Name) - Method in class org.codehaus.activemq.jndi.ReadOnlyContext
 
listeners - Variable in class org.codehaus.activemq.capacity.DelegateCapacityMonitor
 
listeners - Variable in class org.codehaus.activemq.filter.MultiExpressionEvaluator.ExpressionListenerSet
 
literal() - Method in class org.codehaus.activemq.selector.SelectorParser
 
loadAllMessageContainers() - Method in class org.codehaus.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.codehaus.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.codehaus.activemq.jndi.JNDIReferenceFactory
Retrieve the class loader for a named class
loadClass(String) - Method in class org.codehaus.activemq.util.FactoryFinder
 
loadContainer(String, Destination) - Method in class org.codehaus.activemq.service.impl.MessageContainerManagerSupport
Loads the container for the given name and destination on startup
loadPreparedTransactions(TransactionManager) - Method in interface org.codehaus.activemq.store.PreparedTransactionStore
Called on recovery to re-load any transactions which have prepared but not yet commited
loadPreparedTransactions(TransactionManager) - Method in class org.codehaus.activemq.store.bdb.BDbPreparedTransactionStore
 
loadPreparedTransactions(TransactionManager) - Method in class org.codehaus.activemq.store.jdbc.JDBCPreparedTransactionStore
 
loadPreparedTransactions(TransactionManager) - Method in class org.codehaus.activemq.store.jdbm.JdbmPreparedTransactionStore
 
loadPreparedTransactions(TransactionManager) - Method in class org.codehaus.activemq.store.vm.VMPreparedTransactionStoreImpl
 
loadTransaction(ActiveMQXid, Transaction) - Method in interface org.codehaus.activemq.service.TransactionManager
Called on restart when recovering prepared transactions to reload a transaction from persistent store
loadTransaction(ActiveMQXid, Transaction) - Method in class org.codehaus.activemq.service.impl.TransactionManagerImpl
 
localTransactionCommitted(ConnectionEvent) - Method in class org.codehaus.activemq.ra.DefaultConnectionManager
 
localTransactionCommitted(ConnectionEvent) - Method in class org.codehaus.activemq.ra.SimpleConnectionManager
 
localTransactionRolledback(ConnectionEvent) - Method in class org.codehaus.activemq.ra.DefaultConnectionManager
 
localTransactionRolledback(ConnectionEvent) - Method in class org.codehaus.activemq.ra.SimpleConnectionManager
 
localTransactionStarted(ConnectionEvent) - Method in class org.codehaus.activemq.ra.DefaultConnectionManager
 
localTransactionStarted(ConnectionEvent) - Method in class org.codehaus.activemq.ra.SimpleConnectionManager
 
log - Static variable in class org.codehaus.activemq.jndi.JNDIReferenceFactory
 
log - Static variable in class org.codehaus.activemq.transport.ember.EmberTransportChannelFactory
 
logger - Variable in class org.codehaus.activemq.spring.ActiveMQDtdResolver
 
longFromBytes(byte[]) - Static method in class org.codehaus.activemq.store.bdb.BDbHelper
 
lookingAhead - Variable in class org.codehaus.activemq.selector.SelectorParser
 
lookup(String) - Method in class org.codehaus.activemq.jndi.ReadOnlyContext
 
lookup(Name) - Method in class org.codehaus.activemq.jndi.ReadOnlyContext
 
lookupLink(String) - Method in class org.codehaus.activemq.jndi.ReadOnlyContext
 
lookupLink(Name) - Method in class org.codehaus.activemq.jndi.ReadOnlyContext
 

M

MARK_RECORD_SIZE - Static variable in class org.codehaus.activemq.journal.impl.Mark
 
MARK_RECORD_TYPE - Static variable in class org.codehaus.activemq.journal.impl.LogFile
 
MESSAGE_READ_INDEX - Static variable in class org.codehaus.activemq.message.MessageAck
 
Main - class org.codehaus.activemq.broker.impl.Main.
A simple command line tool which runs a JMS Message Broker on the command line
Main() - Constructor for class org.codehaus.activemq.broker.impl.Main
 
Main - class org.codehaus.activemq.spring.Main.
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.codehaus.activemq.spring.Main
 
MapHelper - class org.codehaus.activemq.util.MapHelper.
A bunch of utility methods for working with maps
MapHelper() - Constructor for class org.codehaus.activemq.util.MapHelper
 
Mark - class org.codehaus.activemq.journal.impl.Mark.
Serializes/Deserializes Mark records.
Mark() - Constructor for class org.codehaus.activemq.journal.impl.Mark
 
Mark(RecordLocationImpl) - Constructor for class org.codehaus.activemq.journal.impl.Mark
 
MemoryBoundedQueue - class org.codehaus.activemq.message.util.MemoryBoundedQueue.
MemoryBoundedQueue is a queue bounded by memory usage for Packets
MemoryBoundedQueue(String, MemoryBoundedQueueManager) - Constructor for class org.codehaus.activemq.message.util.MemoryBoundedQueue
Constructor
MemoryBoundedQueueManager - class org.codehaus.activemq.message.util.MemoryBoundedQueueManager.
A factory manager for MemoryBoundedQueue and also ensures that the maximum memory used by all active MemoryBoundedQueues cewated by this instance stays within the memory usage bounds set.
MemoryBoundedQueueManager(String, long) - Constructor for class org.codehaus.activemq.message.util.MemoryBoundedQueueManager
 
MessageAck - class org.codehaus.activemq.message.MessageAck.
Denotes an object that can be serialized/deserailized using a PacketReader/PacketWriter
MessageAck() - Constructor for class org.codehaus.activemq.message.MessageAck
 
MessageAckReader - class org.codehaus.activemq.message.MessageAckReader.
Reads a ConsumerInfo object from a Stream
MessageAckReader() - Constructor for class org.codehaus.activemq.message.MessageAckReader
 
MessageAckTransactionTask - class org.codehaus.activemq.service.impl.MessageAckTransactionTask.
Acknowledge a message as part of XA
MessageAckTransactionTask(BrokerClient, MessageAck) - Constructor for class org.codehaus.activemq.service.impl.MessageAckTransactionTask
 
MessageAckWriter - class org.codehaus.activemq.message.MessageAckWriter.
Writes a ConsumerInfo object to a Stream
MessageAckWriter() - Constructor for class org.codehaus.activemq.message.MessageAckWriter
 
MessageAcknowledge - interface org.codehaus.activemq.message.MessageAcknowledge.
Called when a Message is Acknowledged
MessageCache - interface org.codehaus.activemq.store.cache.MessageCache.
Defines the interface used to cache messages.
MessageContainer - interface org.codehaus.activemq.service.MessageContainer.
A MessageContainer holds the messages for a particular destination
MessageContainerManager - interface org.codehaus.activemq.service.MessageContainerManager.
A manager of MessageContainer instances
MessageContainerManagerSupport - class org.codehaus.activemq.service.impl.MessageContainerManagerSupport.
 
MessageContainerManagerSupport(Dispatcher) - Constructor for class org.codehaus.activemq.service.impl.MessageContainerManagerSupport
 
MessageEntry - class org.codehaus.activemq.service.impl.MessageEntry.
An entry for a message in a container
MessageEntry() - Constructor for class org.codehaus.activemq.service.impl.MessageEntry
Only used by serialisation
MessageEntry(ActiveMQMessage) - Constructor for class org.codehaus.activemq.service.impl.MessageEntry
 
MessageIdentity - class org.codehaus.activemq.service.MessageIdentity.
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.codehaus.activemq.service.MessageIdentity
 
MessageIdentity(String) - Constructor for class org.codehaus.activemq.service.MessageIdentity
 
MessageIdentity(String, Object) - Constructor for class org.codehaus.activemq.service.MessageIdentity
 
MessageListenerSupport - class org.codehaus.activemq.util.MessageListenerSupport.
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.codehaus.activemq.util.MessageListenerSupport
 
MessagePointer - class org.codehaus.activemq.service.impl.MessagePointer.
An entry for a message to be dispatched
MessagePointer(MessageContainer, MessageIdentity) - Constructor for class org.codehaus.activemq.service.impl.MessagePointer
Create a message ptr
MessageServlet - class org.codehaus.activemq.web.MessageServlet.
A servlet for sending and receiving messages to/from JMS destinations using HTTP POST for sending and HTTP GET for receiving.
MessageServlet() - Constructor for class org.codehaus.activemq.web.MessageServlet
 
MessageServletSupport - class org.codehaus.activemq.web.MessageServletSupport.
A useful base class for any JMS related servlet; there are various ways to map JMS operations to web requests so we put most of the common behaviour in a reusable base class.
MessageServletSupport() - Constructor for class org.codehaus.activemq.web.MessageServletSupport
 
MessageStore - interface org.codehaus.activemq.store.MessageStore.
Represents a message store which is used by the persistent MessageContainer implementations
MultiExpressionEvaluator - class org.codehaus.activemq.filter.MultiExpressionEvaluator.
A MultiExpressionEvaluator is used to evaluate multiple expressions in single method call.
MultiExpressionEvaluator() - Constructor for class org.codehaus.activemq.filter.MultiExpressionEvaluator
 
MultiExpressionEvaluator.CacheExpression - class org.codehaus.activemq.filter.MultiExpressionEvaluator.CacheExpression.
A UnaryExpression that caches the result of the nested expression.
MultiExpressionEvaluator.CacheExpression(Expression) - Constructor for class org.codehaus.activemq.filter.MultiExpressionEvaluator.CacheExpression
 
MultiExpressionEvaluator.ExpressionListener - interface org.codehaus.activemq.filter.MultiExpressionEvaluator.ExpressionListener.
Objects that are interested in the results of an expression should implement this interface.
MultiExpressionEvaluator.ExpressionListenerSet - class org.codehaus.activemq.filter.MultiExpressionEvaluator.ExpressionListenerSet.
Multiple listeners my be interested in the results of a single expression.
MultiExpressionEvaluator.ExpressionListenerSet() - Constructor for class org.codehaus.activemq.filter.MultiExpressionEvaluator.ExpressionListenerSet
 
MulticastTransportChannel - class org.codehaus.activemq.transport.multicast.MulticastTransportChannel.
A multicast implementation of a TransportChannel
MulticastTransportChannel(WireFormat, URI) - Constructor for class org.codehaus.activemq.transport.multicast.MulticastTransportChannel
Connect to a remote Node - e.g.
MulticastTransportChannel(WireFormat, MulticastSocket) - Constructor for class org.codehaus.activemq.transport.multicast.MulticastTransportChannel
 
MulticastTransportChannelFactory - class org.codehaus.activemq.transport.multicast.MulticastTransportChannelFactory.
A multicast implementation of a TransportChannelFactory
MulticastTransportChannelFactory() - Constructor for class org.codehaus.activemq.transport.multicast.MulticastTransportChannelFactory
 
MulticastTransportServerChannel - class org.codehaus.activemq.transport.multicast.MulticastTransportServerChannel.
A Multicast implementation of TransportServerChannel
MulticastTransportServerChannel(WireFormat, URI) - Constructor for class org.codehaus.activemq.transport.multicast.MulticastTransportServerChannel
 
MulticastTransportServerChannelFactory - class org.codehaus.activemq.transport.multicast.MulticastTransportServerChannelFactory.
A multicast implementation of a TransportServerChannelFactory
MulticastTransportServerChannelFactory() - Constructor for class org.codehaus.activemq.transport.multicast.MulticastTransportServerChannelFactory
 
main(String[]) - Static method in class org.codehaus.activemq.broker.impl.Main
run the Message Broker as a standalone application
main(String[]) - Static method in class org.codehaus.activemq.spring.Main
run the Message Broker as a standalone application
makeConnection() - Static method in class org.codehaus.activemq.ActiveMQConnection
A static helper method to create a new connection
makeConnection(String) - Static method in class org.codehaus.activemq.ActiveMQConnection
A static helper method to create a new connection
makeConnection(String, String, String) - Static method in class org.codehaus.activemq.ActiveMQConnection
A static helper method to create a new connection
makeConnection(ConnectionFactory, ActiveMQConnectionRequestInfo) - Static method in class org.codehaus.activemq.ra.ActiveMQResourceAdapter
A helper method to create a new JMS connection from the connection request info.
makeDefaultContainerManagers() - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
makeMap() - Static method in class org.codehaus.activemq.store.vm.VMTopicMessageStore
 
makeSubscription(Dispatcher, BrokerClient, ConsumerInfo, Filter) - Method in interface org.codehaus.activemq.service.SubscriptionContainer
Creates a subscription (which could be a previous subscription reconecting) and adds it to this container
makeSubscription(Dispatcher, BrokerClient, ConsumerInfo, Filter) - Method in class org.codehaus.activemq.service.impl.SubscriptionContainerImpl
 
manager - Variable in class org.codehaus.activemq.journal.impl.JournalImpl
 
mark - Variable in class org.codehaus.activemq.journal.impl.Record
 
matchManagedConnections(Set, Subject, ConnectionRequestInfo) - Method in class org.codehaus.activemq.ra.ActiveMQManagedConnectionFactory
 
matches(Message) - Method in class org.codehaus.activemq.filter.AndFilter
 
matches(Destination) - Method in class org.codehaus.activemq.filter.CompositeDestinationFilter
 
matches(Message) - Method in class org.codehaus.activemq.filter.DestinationFilter
 
matches(Destination) - Method in class org.codehaus.activemq.filter.DestinationFilter
 
matches(Message) - Method in class org.codehaus.activemq.filter.ExpressionFilter
 
matches(Message) - Method in interface org.codehaus.activemq.filter.Filter
 
matches(Message) - Method in class org.codehaus.activemq.filter.NoLocalFilter
ensure messages are filtered if they have the same clientId as the filter
matches(Message) - Method in class org.codehaus.activemq.filter.NotFilter
 
matches(Message) - Method in class org.codehaus.activemq.filter.OrFilter
 
matches(Destination) - Method in class org.codehaus.activemq.filter.PrefixDestinationFilter
 
matches(Destination) - Method in class org.codehaus.activemq.filter.SimpleDestinationFilter
 
matches(Destination) - Method in class org.codehaus.activemq.filter.WildcardDestinationFilter
 
matches(RecordHeader) - Method in class org.codehaus.activemq.journal.impl.RecordFooter
 
matches(byte[]) - Method in class org.codehaus.activemq.journal.impl.RecordFooter
 
matches(ActiveMQDestination) - Method in class org.codehaus.activemq.message.ActiveMQDestination
Returns true if the given destination matches this destination; including wildcards
matches(Subject, ConnectionRequestInfo) - Method in class org.codehaus.activemq.ra.ActiveMQManagedConnection
 
maximumRetries - Variable in class org.codehaus.activemq.transport.composite.CompositeTransportChannel
 
message - Variable in class org.codehaus.activemq.ra.ActiveMQPollingEndpointWorker.InboundEndpointWork
 
messageConsumed(MessageAck) - Method in interface org.codehaus.activemq.service.Subscription
Indicates a message has been delivered to a MessageConsumer which is typically called for topic based subscriptions
messageConsumed(MessageAck) - Method in class org.codehaus.activemq.service.impl.DurableTopicSubscription
 
messageConsumed(MessageAck) - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
Indicates a message has been delivered to a MessageConsumer
messageContainers - Variable in class org.codehaus.activemq.service.impl.MessageContainerManagerSupport
 
messageCount - Variable in class org.codehaus.activemq.management.JMSEndpointStatsImpl
 
messageDelivered(boolean, ActiveMQMessage, boolean) - Method in class org.codehaus.activemq.ActiveMQSession
 
messagePtrs - Variable in class org.codehaus.activemq.service.impl.SubscriptionImpl
 
messageQueue - Variable in class org.codehaus.activemq.ActiveMQConnectionConsumer
 
messageQueue - Variable in class org.codehaus.activemq.ActiveMQMessageConsumer
 
messageRateTime - Variable in class org.codehaus.activemq.management.JMSEndpointStatsImpl
 
messageSelector - Variable in class org.codehaus.activemq.ActiveMQMessageConsumer
 
messageTable - Variable in class org.codehaus.activemq.store.vm.VMMessageStore
 
messageTableName - Variable in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
messageWaitTime - Variable in class org.codehaus.activemq.management.JMSEndpointStatsImpl
 
minus(Number, Number) - Method in class org.codehaus.activemq.filter.ArithmeticExpression
 
mod(Number, Number) - Method in class org.codehaus.activemq.filter.ArithmeticExpression
 
monitor - Variable in class org.codehaus.activemq.capacity.DelegateCapacityMonitor
 
msgIdDataType - Variable in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
multExpr() - Method in class org.codehaus.activemq.selector.SelectorParser
 
multiply(Number, Number) - Method in class org.codehaus.activemq.filter.ArithmeticExpression
 

N

NAME - Static variable in class org.codehaus.activemq.util.BeanUtils
 
NEWINSTANCE_PARAMETER_TYPES - Static variable in class org.codehaus.activemq.broker.impl.DefaultBroker
 
NOT - Static variable in interface org.codehaus.activemq.selector.SelectorParserConstants
 
NOT_SET - Static variable in interface org.codehaus.activemq.message.TransactionType
Transaction state not set
NO_CHECKSUM_ALGORITHIM - Static variable in class org.codehaus.activemq.journal.impl.RecordFooter
 
NULL - Static variable in class org.codehaus.activemq.filter.ConstantExpression
 
NULL - Static variable in class org.codehaus.activemq.message.ActiveMQMessage
 
NULL - Static variable in interface org.codehaus.activemq.selector.SelectorParserConstants
 
NameParserImpl - class org.codehaus.activemq.jndi.NameParserImpl.
A default implementation of NameParser
NameParserImpl() - Constructor for class org.codehaus.activemq.jndi.NameParserImpl
 
NetworkChannel - class org.codehaus.activemq.transport.NetworkChannel.
Represents a broker's connection with a single remote broker which bridges the two brokers to form a network.
NetworkChannel() - Constructor for class org.codehaus.activemq.transport.NetworkChannel
Default Constructor
NetworkChannel(BrokerContainer, String) - Constructor for class org.codehaus.activemq.transport.NetworkChannel
Constructor
NetworkConnector - class org.codehaus.activemq.transport.NetworkConnector.
Represents a connector to one or more remote brokers.
NetworkConnector(BrokerContainer) - Constructor for class org.codehaus.activemq.transport.NetworkConnector
 
NetworkMessageBridge - class org.codehaus.activemq.transport.NetworkMessageBridge.
A NetworkMessageBridge consumes messages from a remote broker and daisy chains them to the local message producer, which will pass them into the local broker for consumption
NetworkMessageBridge() - Constructor for class org.codehaus.activemq.transport.NetworkMessageBridge
Construct the NetworkMessageConsumer
NoDestinationSuppliedException - exception org.codehaus.activemq.web.NoDestinationSuppliedException.
Exception thrown if there was no destination available
NoDestinationSuppliedException() - Constructor for class org.codehaus.activemq.web.NoDestinationSuppliedException
 
NoLocalFilter - class org.codehaus.activemq.filter.NoLocalFilter.
Checks that messages are not filtered by NoLocal
NoLocalFilter(String) - Constructor for class org.codehaus.activemq.filter.NoLocalFilter
Construct a NoLocalFilter
NotFilter - class org.codehaus.activemq.filter.NotFilter.
Represents a logical not operation on another filter
NotFilter(Filter) - Constructor for class org.codehaus.activemq.filter.NotFilter
 
NotStartedException - exception org.codehaus.activemq.NotStartedException.
An exception thrown when an operation is invoked on a service which has not yet been started.
NotStartedException() - Constructor for class org.codehaus.activemq.NotStartedException
 
name - Variable in class org.codehaus.activemq.capacity.DelegateCapacityMonitor
 
nameParser - Static variable in class org.codehaus.activemq.jndi.ReadOnlyContext
 
newClient(ByteArrayServerClient) - Method in class org.codehaus.activemq.transport.ember.EmberTransportServerChannel
 
newContext() - Method in class org.codehaus.activemq.jndi.ReadOnlyContext
 
newFactory(String) - Static method in class org.codehaus.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.
newIOException(JMSException) - Static method in class org.codehaus.activemq.util.JMSExceptionHelper
 
newInstance(String, Resource) - Static method in class org.codehaus.activemq.spring.ActiveMQBeanFactory
A static factory method which can be used easily from spring.xml
newInstance(Resource, String) - Static method in class org.codehaus.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.codehaus.activemq.store.bdb.BDbPersistenceAdapter
Factory method to create an instance using the defaults
newInstance(File) - Static method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
Factory method to create an instance using the defaults
newInstance(File) - Static method in class org.codehaus.activemq.store.jdbm.JdbmPersistenceAdapter
Factory method to create an instance using the defaults
newInstance(File) - Static method in class org.codehaus.activemq.store.journal.JournalPersistenceAdapter
Factory method to create an instance using the defaults
newInstance(File) - Static method in class org.codehaus.activemq.store.vm.VMPersistenceAdapter
 
newInstance(WireFormat, String) - Static method in class org.codehaus.activemq.transport.TransportServerChannelProvider
Create a Channel used for the Broker to listen to remove connections
newInstance(String) - Method in class org.codehaus.activemq.util.FactoryFinder
Creates a new instance of the given key
newJMSException(String, Throwable) - Static method in class org.codehaus.activemq.util.JMSExceptionHelper
 
newJMSException(String, Exception) - Static method in class org.codehaus.activemq.util.JMSExceptionHelper
 
newJMSException(Throwable) - Static method in class org.codehaus.activemq.util.JMSExceptionHelper
 
newMessage(ByteArrayServerClient, Object) - Method in class org.codehaus.activemq.transport.ember.EmberTransportChannel
 
newMessage(ByteArrayServerClient, Object) - Method in class org.codehaus.activemq.transport.ember.EmberTransportServerChannel
 
newToken(int) - Static method in class org.codehaus.activemq.selector.Token
Returns a new Token object, by default.
next - Variable in class org.codehaus.activemq.selector.Token
A reference to the next regular (non-special) token from the input stream.
next - Variable in class org.codehaus.activemq.service.impl.DefaultQueueListEntry
 
nextByte() - Method in class org.codehaus.activemq.transport.reliable.SMLCGRandom
 
nextDouble() - Method in class org.codehaus.activemq.transport.reliable.SMLCGRandom
 
nextElement() - Method in class org.codehaus.activemq.ActiveMQQueueBrowser
 
nextFloat() - Method in class org.codehaus.activemq.transport.reliable.SMLCGRandom
 
nextInt() - Method in class org.codehaus.activemq.transport.reliable.SMLCGRandom
 
nextKey - Variable in class org.codehaus.activemq.service.impl.QueueListSupport.Node
 
nextLong() - Method in class org.codehaus.activemq.transport.reliable.SMLCGRandom
 
nextShort() - Method in class org.codehaus.activemq.transport.reliable.SMLCGRandom
 
nextUsedSession - Variable in class org.codehaus.activemq.ra.ActiveMQAsfEndpointWorker.ServerSessionPoolImpl
 
noLocal - Variable in class org.codehaus.activemq.ActiveMQMessageConsumer
 
noLocal - Variable in class org.codehaus.activemq.ra.ActiveMQActivationSpec
 
notifyWaiting() - Method in class org.codehaus.activemq.ra.CircularQueue
 

O

ON_MESSAGE_METHOD - Static variable in class org.codehaus.activemq.ra.ActiveMQBaseEndpointWorker
 
OR - Static variable in interface org.codehaus.activemq.selector.SelectorParserConstants
 
OrFilter - class org.codehaus.activemq.filter.OrFilter.
Represents a logical OR operation on two filters
OrFilter(Filter, Filter) - Constructor for class org.codehaus.activemq.filter.OrFilter
 
objectToData(Object, DataBuffer) - Method in class org.codehaus.activemq.store.bdbn.StringDataBinding
 
offsetId - Variable in class org.codehaus.activemq.journal.impl.Mark
 
onAcknowledgeTransactedMessageBeforeCommit(MessageAck) - Method in interface org.codehaus.activemq.service.Subscription
We have not yet committed and so the message acknowledgement has not really occurred yet but we need to let the dispatcher know that we can commence dispatching more messages to the client.
onAcknowledgeTransactedMessageBeforeCommit(MessageAck) - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
 
onAsyncException(JMSException) - Method in class org.codehaus.activemq.transport.TransportChannelSupport
Handles an exception thrown while performing async dispatch of messages
onConnectionClose(ActiveMQConnection) - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
Called when a connection is closed so that we can shut down any embedded brokers cleanly
onConnectionCreate(ActiveMQConnection) - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
 
onConsumerInfo(BrokerClient, ConsumerInfo) - Method in interface org.codehaus.activemq.broker.ConsumerInfoListener
ConsumerInfo packet fired from within the broker
onConsumerInfo(BrokerClient, ConsumerInfo) - Method in class org.codehaus.activemq.transport.NetworkChannel
Listen for new Consumer events at this broker
onCreateDurableSubscriber() - Method in class org.codehaus.activemq.management.JMSSessionStatsImpl
 
onException(JMSException) - Method in class org.codehaus.activemq.ActiveMQConnection
 
onException(JMSException) - Method in class org.codehaus.activemq.broker.impl.BrokerClientImpl
 
onException(JMSException) - Method in class org.codehaus.activemq.transport.reliable.ReliableTransportChannel
handle exception from the embedded channel
onJMSException(JMSException, Message) - Method in class org.codehaus.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.codehaus.activemq.management.JMSEndpointStatsImpl
 
onMessage(Message) - Method in class org.codehaus.activemq.ra.ActiveMQAsfEndpointWorker.ServerSessionImpl
 
onMessage(long, String) - Method in interface org.codehaus.activemq.store.jdbc.JDBCAdapter.MessageListResultHandler
 
onMessage(Message) - Method in class org.codehaus.activemq.transport.NetworkMessageBridge
 
onMessage(Message) - Method in class org.codehaus.activemq.util.MessageListenerSupport
 
onMessageAck() - Method in interface org.codehaus.activemq.management.JMSDestinationStats
On a consume from this destination, updates the consumed states
onMessageAck() - Method in class org.codehaus.activemq.management.JMSQueueStatsImpl
 
onMessageAck() - Method in class org.codehaus.activemq.management.JMSTopicStatsImpl
 
onMessageRemove(HowlMessageStore) - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
onMessageSend(Message) - Method in interface org.codehaus.activemq.management.JMSDestinationStats
On a message send to this destination, update the producing stats
onMessageSend(Message) - Method in class org.codehaus.activemq.management.JMSQueueStatsImpl
 
onMessageSend(Message) - Method in class org.codehaus.activemq.management.JMSTopicStatsImpl
 
onRemoveDurableSubscriber() - Method in class org.codehaus.activemq.management.JMSSessionStatsImpl
 
open(DbEnv, String, boolean) - Static method in class org.codehaus.activemq.store.bdbn.BDbHelper
 
orExpression() - Method in class org.codehaus.activemq.selector.SelectorParser
 
org.codehaus.activemq - package org.codehaus.activemq
The core JMS client implementation classes
org.codehaus.activemq.axis - package org.codehaus.activemq.axis
Support classes for integration with Apache Axis for web service integration
org.codehaus.activemq.broker - package org.codehaus.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.codehaus.activemq.broker.impl - package org.codehaus.activemq.broker.impl
The default implementation of the JMS Broker
org.codehaus.activemq.capacity - package org.codehaus.activemq.capacity
 
org.codehaus.activemq.filter - package org.codehaus.activemq.filter
Filter implementations for wildcards & JMS selectors
org.codehaus.activemq.gbean - package org.codehaus.activemq.gbean
The JMS container using GBeaps for deployment in Geronimo or other JSR 77/88 based containers
org.codehaus.activemq.jndi - package org.codehaus.activemq.jndi
JNDI helper classes
org.codehaus.activemq.journal - package org.codehaus.activemq.journal
Provides the API for storing and accessing record based binary data in sequential log files.
org.codehaus.activemq.journal.howl - package org.codehaus.activemq.journal.howl
A Journal implemenation using using a high performance transaction log implemented using Howl
org.codehaus.activemq.journal.impl - package org.codehaus.activemq.journal.impl
A custom high performance Journal implemenation.
org.codehaus.activemq.management - package org.codehaus.activemq.management
An implementation of the J2EE Management API
org.codehaus.activemq.message - package org.codehaus.activemq.message
Message implementations
org.codehaus.activemq.message.util - package org.codehaus.activemq.message.util
 
org.codehaus.activemq.ra - package org.codehaus.activemq.ra
JCA managed connections and resource adapters for working with ActiveMQ
org.codehaus.activemq.security - package org.codehaus.activemq.security
Plugable Security Adapter framework along with default implementations such as the JAAS implementation.
org.codehaus.activemq.selector - package org.codehaus.activemq.selector
JMS Selector parser
org.codehaus.activemq.service - package org.codehaus.activemq.service
The core services which make up the JMS Message Broker such as the Store, MessageContainer and MessageContainerManager
org.codehaus.activemq.service.boundedvm - package org.codehaus.activemq.service.boundedvm
 
org.codehaus.activemq.service.impl - package org.codehaus.activemq.service.impl
Default implementations of the services
org.codehaus.activemq.spring - package org.codehaus.activemq.spring
Utilities for loading a Message Broker using Spring's XML deployment mechanism
org.codehaus.activemq.store - package org.codehaus.activemq.store
The APIs which need to be implemented for persistent message stores for durable messaging
org.codehaus.activemq.store.bdb - package org.codehaus.activemq.store.bdb
Message persistence implemented using Berkeley DB Java Edition
org.codehaus.activemq.store.bdbn - package org.codehaus.activemq.store.bdbn
Message persistence implemented using Berkeley DB, native C version
org.codehaus.activemq.store.cache - package org.codehaus.activemq.store.cache
 
org.codehaus.activemq.store.howl - package org.codehaus.activemq.store.howl
Message persistence using a high performance transaction log via implemented using Howl whichi is used for short term persistence with longer term storage being used at checkpoints.
org.codehaus.activemq.store.jdbc - package org.codehaus.activemq.store.jdbc
Message persistence implemented using JDBC
org.codehaus.activemq.store.jdbc.adapter - package org.codehaus.activemq.store.jdbc.adapter
Implements database/driver apapters to compensate for the wide differences in the BLOB handing of JDBC drivers.
org.codehaus.activemq.store.jdbm - package org.codehaus.activemq.store.jdbm
Message persistence implemented using JDBM which is the default persistence mechanism shipped with Geronimo (due to its BSD licence)
org.codehaus.activemq.store.journal - package org.codehaus.activemq.store.journal
Message persistence using a high performance transaction log via the Journal interface.
org.codehaus.activemq.store.vm - package org.codehaus.activemq.store.vm
VM based implementation of message persistence
org.codehaus.activemq.transport - package org.codehaus.activemq.transport
The transport abstraction layer for sending and receiving Packets over a network
org.codehaus.activemq.transport.composite - package org.codehaus.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.codehaus.activemq.transport.ember - package org.codehaus.activemq.transport.ember
An implementation of the transport layer using EmberIO for efficient NIO
org.codehaus.activemq.transport.gnet - package org.codehaus.activemq.transport.gnet
An implementation of the transport layer using the Geronimo networking layer.
org.codehaus.activemq.transport.http - package org.codehaus.activemq.transport.http
A transport using the HTTP protocol to allow ActiveMQ to tunnel through firewalls.
org.codehaus.activemq.transport.jabber - package org.codehaus.activemq.transport.jabber
 
org.codehaus.activemq.transport.jgroups - package org.codehaus.activemq.transport.jgroups
An implementation of the transport layer using JGroups
org.codehaus.activemq.transport.jrms - package org.codehaus.activemq.transport.jrms
An implementation of the transport layer using Sun's reliable multicast library
org.codehaus.activemq.transport.jxta - package org.codehaus.activemq.transport.jxta
An implementation of the transport layer using JXTA P2PSockets for navigating firewalls and NATs
org.codehaus.activemq.transport.multicast - package org.codehaus.activemq.transport.multicast
An implementation of the transport layer using multicast
org.codehaus.activemq.transport.reliable - package org.codehaus.activemq.transport.reliable
 
org.codehaus.activemq.transport.ssl - package org.codehaus.activemq.transport.ssl
An implementation of the transport layer using SSL over TCP/IP sockets
org.codehaus.activemq.transport.tcp - package org.codehaus.activemq.transport.tcp
An implementation of the transport layer using TCP/IP sockets
org.codehaus.activemq.transport.udp - package org.codehaus.activemq.transport.udp
An implementation of the transport layer using UDP
org.codehaus.activemq.transport.vm - package org.codehaus.activemq.transport.vm
An implementation of the transport layer using intra-JVM communication
org.codehaus.activemq.transport.xstream - package org.codehaus.activemq.transport.xstream
 
org.codehaus.activemq.transport.zeroconf - package org.codehaus.activemq.transport.zeroconf
A discovery agent using Zeroconf via the jmDNS library
org.codehaus.activemq.util - package org.codehaus.activemq.util
Utility classes like a SEDA style Command pattern helper and a BitArray for working with flags etc.
org.codehaus.activemq.web - package org.codehaus.activemq.web
Web Connectors so that messages can be sent via HTTP POST or read via HTTP POST or GET as well as support for web streaming to we browser or JavaScript clients.
overflowNotification(RecordLocation) - Method in interface org.codehaus.activemq.journal.JournalEventListener
This event is issues when a Journal implementations wants to recover disk space used by old records.
overflowNotification(RecordLocation) - Method in class org.codehaus.activemq.store.journal.JournalPersistenceAdapter
The Journal give us a call back so that we can move old data out of the journal.

P

PARAMETER_TYPES - Static variable in class org.codehaus.activemq.util.BeanUtils
 
PAYLOAD_INDEX - Static variable in class org.codehaus.activemq.message.ActiveMQMessage
 
PERSISTENCE_ADAPTER_PROPERTY - Static variable in class org.codehaus.activemq.broker.impl.DefaultBroker
 
PERSISTENT_INDEX - Static variable in class org.codehaus.activemq.message.MessageAck
 
PREPARED_STATE - Static variable in class org.codehaus.activemq.service.impl.AbstractTransaction
 
PRE_COMMIT - Static variable in interface org.codehaus.activemq.message.TransactionType
Pre-commit a transaction
PRODUCER_INFO - Static variable in interface org.codehaus.activemq.message.Packet
Producer Info
PROPERTIES_INDEX - Static variable in class org.codehaus.activemq.message.ActiveMQMessage
 
PROPERTY_STORE_DIRECTORY - Static variable in class org.codehaus.activemq.broker.impl.DefaultBroker
 
Packet - interface org.codehaus.activemq.message.Packet.
Denotes an object that can be serialized/deserailized using a PacketReader or PacketWriter
PacketFacade - class org.codehaus.activemq.message.PacketFacade.
A helper class for using Packet instances with object serialization
PacketFacade() - Constructor for class org.codehaus.activemq.message.PacketFacade
 
PacketFacade(Packet) - Constructor for class org.codehaus.activemq.message.PacketFacade
 
PacketListener - interface org.codehaus.activemq.message.PacketListener.
Listener for Packets
PacketReader - interface org.codehaus.activemq.message.PacketReader.
Allows instances implementing Packet to read from a DataOutputStream
PacketTransactionTask - class org.codehaus.activemq.service.impl.PacketTransactionTask.
 
PacketTransactionTask(BrokerClient, Packet) - Constructor for class org.codehaus.activemq.service.impl.PacketTransactionTask
 
PacketWriter - interface org.codehaus.activemq.message.PacketWriter.
Allows instances implementing Packet to written to a DataOutput
ParseException - exception org.codehaus.activemq.selector.ParseException.
This exception is thrown when parse errors are encountered.
ParseException(Token, int[][], String[]) - Constructor for class org.codehaus.activemq.selector.ParseException
This constructor is used by the method "generateParseException" in the generated parser.
ParseException() - Constructor for class org.codehaus.activemq.selector.ParseException
The following constructors are for use by you for whatever purpose you can think of.
ParseException(String) - Constructor for class org.codehaus.activemq.selector.ParseException
 
PersistenceAdapter - interface org.codehaus.activemq.store.PersistenceAdapter.
Adapter to the actual persistence mechanism used with ActiveMQ
PersistenceAdapterSupport - class org.codehaus.activemq.service.impl.PersistenceAdapterSupport.
Abstract base class useful for implementation inheritence
PersistenceAdapterSupport() - Constructor for class org.codehaus.activemq.service.impl.PersistenceAdapterSupport
 
PrefixDestinationFilter - class org.codehaus.activemq.filter.PrefixDestinationFilter.
Matches messages which match a prefix like "A.B.>"
PrefixDestinationFilter(String[]) - Constructor for class org.codehaus.activemq.filter.PrefixDestinationFilter
An array of paths, the last path is '>'
PreparedTransactionStore - interface org.codehaus.activemq.store.PreparedTransactionStore.
Represents a durable store of a prepare log for XA
ProducerInfo - class org.codehaus.activemq.message.ProducerInfo.
Denotes life cycle infomation for a Producer of messages
ProducerInfo() - Constructor for class org.codehaus.activemq.message.ProducerInfo
 
ProducerInfoReader - class org.codehaus.activemq.message.ProducerInfoReader.
Reads a ProducerInfo object from a Stream
ProducerInfoReader() - Constructor for class org.codehaus.activemq.message.ProducerInfoReader
 
ProducerInfoWriter - class org.codehaus.activemq.message.ProducerInfoWriter.
Writes a ProducerInfo object to a Stream
ProducerInfoWriter() - Constructor for class org.codehaus.activemq.message.ProducerInfoWriter
 
PropertyExpression - class org.codehaus.activemq.filter.PropertyExpression.
Represents a property expression
PropertyExpression(String) - Constructor for class org.codehaus.activemq.filter.PropertyExpression
 
ProxyMessageContainerManager - class org.codehaus.activemq.service.impl.ProxyMessageContainerManager.
A Proxy implementation of MessageContainerManager which delegates to some other implementation which is useful for writing Facade implementations
ProxyMessageContainerManager() - Constructor for class org.codehaus.activemq.service.impl.ProxyMessageContainerManager
 
ProxyMessageContainerManager(MessageContainerManager) - Constructor for class org.codehaus.activemq.service.impl.ProxyMessageContainerManager
 
packetIdGenerator - Variable in class org.codehaus.activemq.ActiveMQConnection
 
packetIdGenerator - Variable in class org.codehaus.activemq.ActiveMQSession
 
parse(String) - Method in class org.codehaus.activemq.jndi.NameParserImpl
 
parse(String) - Method in class org.codehaus.activemq.selector.SelectorParser
 
parseFilter(Destination) - Static method in class org.codehaus.activemq.filter.DestinationFilter
 
parseQuery(URI) - Static method in class org.codehaus.activemq.util.URIHelper
Parsers the query string of the URI into a map of key-value pairs
parseQuery(String) - Static method in class org.codehaus.activemq.util.URIHelper
Parsers the query string of the URI into a map of key-value pairs
parseURIs(URI) - Method in class org.codehaus.activemq.transport.composite.CompositeTransportChannelFactory
 
password - Variable in class org.codehaus.activemq.ActiveMQConnectionFactory
 
password - Variable in class org.codehaus.activemq.message.ConnectionInfo
 
password - Variable in class org.codehaus.activemq.ra.ActiveMQConnectionRequestInfo
 
peekConnection() - Static method in class org.codehaus.activemq.store.jdbc.TransactionContext
 
peekNext(MessageIdentity) - Method in interface org.codehaus.activemq.service.QueueMessageContainer
Used for browsing a MessageContainer this returns the next message in the container after the messageId
peekNext(MessageIdentity) - Method in class org.codehaus.activemq.service.impl.DurableQueueMessageContainer
 
pendingMessageCount - Variable in class org.codehaus.activemq.management.JMSEndpointStatsImpl
 
pendingStop - Variable in class org.codehaus.activemq.transport.TransportChannelSupport
 
persistenceAdapter - Variable in class org.codehaus.activemq.store.jdbc.JDBCMessageStore
 
plus(Number, Number) - Method in class org.codehaus.activemq.filter.ArithmeticExpression
 
poll() - Method in interface org.codehaus.activemq.service.MessageContainerManager
Poll for messages
poll() - Method in interface org.codehaus.activemq.service.QueueMessageContainer
Some implementations may need to poll to fill subscriptions this returns the next message in the container
poll() - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageManager
 
poll() - Method in class org.codehaus.activemq.service.boundedvm.TransientTopicBoundedMessageManager
 
poll() - Method in class org.codehaus.activemq.service.impl.DurableQueueMessageContainer
 
poll() - Method in class org.codehaus.activemq.service.impl.DurableQueueMessageContainerManager
Poll for messages
poll() - Method in class org.codehaus.activemq.service.impl.DurableTopicMessageContainerManager
poll or messages
poll() - Method in class org.codehaus.activemq.service.impl.ProxyMessageContainerManager
 
popConnection() - Static method in class org.codehaus.activemq.store.jdbc.TransactionContext
Pops off the current Connection from the stack
popTransaction() - Static method in class org.codehaus.activemq.store.bdb.BDbHelper
Pops off the current transaction from the stack
popTransaction() - Static method in class org.codehaus.activemq.store.bdbn.BDbHelper
Pops off the current transaction from the stack
populate(Object, Map) - Static method in class org.codehaus.activemq.util.BeanUtils
 
populateProperties(Properties) - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
Initialize the instance from properties stored in JNDI
populateProperties(Properties) - Method in class org.codehaus.activemq.jndi.JNDIBaseStorable
Initialize the instance from properties stored in JNDI
populateProperties(Properties) - Method in class org.codehaus.activemq.message.ActiveMQDestination
Initialize the instance from properties stored in JNDI
populateProperties(TransportChannel, URI) - Method in class org.codehaus.activemq.transport.TransportChannelFactorySupport
If a query string is present in the URI then set any simple bean properties on the channel
port - Variable in class org.codehaus.activemq.transport.udp.UdpTransportChannel
 
postCommit() - Method in class org.codehaus.activemq.service.impl.AbstractTransaction
 
postRollback() - Method in class org.codehaus.activemq.service.impl.AbstractTransaction
 
prePrepare() - Method in class org.codehaus.activemq.service.impl.AbstractTransaction
 
prefetchNumber - Variable in class org.codehaus.activemq.ActiveMQMessageConsumer
 
prepare(Xid) - Method in class org.codehaus.activemq.ActiveMQXASession
 
prepare() - Method in interface org.codehaus.activemq.service.Transaction
 
prepare() - Method in class org.codehaus.activemq.service.impl.LocalTransactionCommand
 
prepare() - Method in class org.codehaus.activemq.service.impl.XATransactionCommand
 
prepareMessageBody() - Method in class org.codehaus.activemq.message.ActiveMQMessage
Prepare a message body for delivery
prepareMessageBody() - Method in class org.codehaus.activemq.message.ActiveMQObjectMessage
Prepare a message body for delivery
prepareTransaction(BrokerClient, ActiveMQXid) - Method in interface org.codehaus.activemq.broker.Broker
 
prepareTransaction(BrokerClient, ActiveMQXid) - Method in interface org.codehaus.activemq.broker.BrokerConnector
Prepare an XA transaction.
prepareTransaction(BrokerClient, ActiveMQXid) - Method in interface org.codehaus.activemq.broker.BrokerContainer
Prepare an XA transaction.
prepareTransaction(BrokerClient, ActiveMQXid) - Method in class org.codehaus.activemq.broker.impl.BrokerConnectorImpl
Prepare an XA transaction.
prepareTransaction(BrokerClient, ActiveMQXid) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
Prepare an XA transaction.
prepareTransaction(BrokerClient, ActiveMQXid) - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
Prepares an XA Transaciton.
previous - Variable in class org.codehaus.activemq.service.impl.DefaultQueueListEntry
 
previousKey - Variable in class org.codehaus.activemq.service.impl.QueueListSupport.Node
 
primaryExpr() - Method in class org.codehaus.activemq.selector.SelectorParser
 
print(String) - Method in class org.codehaus.activemq.util.IndentPrinter
 
printIndent() - Method in class org.codehaus.activemq.util.IndentPrinter
 
println(Object) - Method in class org.codehaus.activemq.util.IndentPrinter
 
println(String) - Method in class org.codehaus.activemq.util.IndentPrinter
 
println() - Method in class org.codehaus.activemq.util.IndentPrinter
 
processMessage(ActiveMQMessage) - Method in class org.codehaus.activemq.ActiveMQMessageConsumer
Process a Message - passing either to the queue or message listener
processMessage(Message) - Method in class org.codehaus.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.codehaus.activemq.service.impl.DurableQueueMessageContainerManager
 
producerId - Variable in class org.codehaus.activemq.ActiveMQMessageProducer
 
producers - Variable in class org.codehaus.activemq.ActiveMQSession
 
properties - Variable in class org.codehaus.activemq.message.ConnectionInfo
 
propertyExists(String) - Method in class org.codehaus.activemq.message.ActiveMQMessage
Indicates whether a property value exists.
proxyClosedEvent(JMSConnectionProxy) - Method in class org.codehaus.activemq.ra.ActiveMQManagedConnection
When a proxy is closed this cleans up the proxy and notifys the ConnectionEventListeners that a connection closed.
publish(Message) - Method in class org.codehaus.activemq.ActiveMQTopicPublisher
Publishes a message to the topic.
publish(Message, int, int, long) - Method in class org.codehaus.activemq.ActiveMQTopicPublisher
Publishes a message to the topic, specifying delivery mode, priority, and time to live.
publish(Topic, Message) - Method in class org.codehaus.activemq.ActiveMQTopicPublisher
Publishes a message to a topic for an unidentified message producer.
publish(Topic, Message, int, int, long) - Method in class org.codehaus.activemq.ActiveMQTopicPublisher
Publishes a message to a topic for an unidentified message producer, specifying delivery mode, priority and time to live.
pushConnection(Connection) - Static method in class org.codehaus.activemq.store.jdbc.TransactionContext
Sets the current transaction, possibly including nesting
pushTransaction(Transaction) - Static method in class org.codehaus.activemq.store.bdb.BDbHelper
Sets the current transaction, possibly including nesting
pushTransaction(DbTxn) - Static method in class org.codehaus.activemq.store.bdbn.BDbHelper
Sets the current transaction, possibly including nesting
put(ActiveMQDestination, Object) - Method in class org.codehaus.activemq.filter.DestinationMap
 
put(ActiveMQXid, Transaction) - Method in interface org.codehaus.activemq.store.PreparedTransactionStore
 
put(ActiveMQXid, Transaction) - Method in class org.codehaus.activemq.store.bdb.BDbPreparedTransactionStore
 
put(String, ActiveMQMessage) - Method in interface org.codehaus.activemq.store.cache.MessageCache
Puts a message into the cache.
put(String, ActiveMQMessage) - Method in class org.codehaus.activemq.store.cache.SimpleMessageCache
Puts a message into the cache.
put(ActiveMQXid, Transaction) - Method in class org.codehaus.activemq.store.jdbc.JDBCPreparedTransactionStore
 
put(ActiveMQXid, Transaction) - Method in class org.codehaus.activemq.store.jdbm.JdbmPreparedTransactionStore
 
put(ActiveMQXid, Transaction) - Method in class org.codehaus.activemq.store.vm.VMPreparedTransactionStoreImpl
 

Q

QCF_CLASS - Static variable in class org.codehaus.activemq.axis.ActiveMQVendorAdapter
 
QueueList - interface org.codehaus.activemq.service.QueueList.
Represents a Queue with List like semantics, allowing addition and removal at any point in the queue.
QueueListEntry - interface org.codehaus.activemq.service.QueueListEntry.
Represents an entry in a linked list
QueueListSupport - class org.codehaus.activemq.service.impl.QueueListSupport.
A base class which is useful for implementation inheritence when implementing a persistent QueueList
QueueListSupport() - Constructor for class org.codehaus.activemq.service.impl.QueueListSupport
 
QueueListSupport.Header - class org.codehaus.activemq.service.impl.QueueListSupport.Header.
 
QueueListSupport.Header() - Constructor for class org.codehaus.activemq.service.impl.QueueListSupport.Header
 
QueueListSupport.Node - class org.codehaus.activemq.service.impl.QueueListSupport.Node.
 
QueueListSupport.Node() - Constructor for class org.codehaus.activemq.service.impl.QueueListSupport.Node
 
QueueMessageContainer - interface org.codehaus.activemq.service.QueueMessageContainer.
A Queue based MessageContainer
queryLatestKeyInDatabase(SecondaryDatabase) - Method in class org.codehaus.activemq.store.bdb.SequenceNumberCreator
 
queueConsumersAttribute - Static variable in class org.codehaus.activemq.web.WebClient
 

R

RECEIPT_INFO - Static variable in interface org.codehaus.activemq.message.Packet
Recipt message
RECEIPT_REQUIRED_INDEX - Static variable in class org.codehaus.activemq.message.AbstractPacket
Message flag indexes (used for writing/reading to/from a Stream
RECONNECTED - Static variable in class org.codehaus.activemq.transport.TransportStatusEvent
The channel has successfully reconnected after a disconnect
RECORD_BASE_SIZE - Static variable in class org.codehaus.activemq.journal.impl.Record
 
RECORD_FOOTER_SIZE - Static variable in class org.codehaus.activemq.journal.impl.RecordFooter
 
RECORD_HEADER_SIZE - Static variable in class org.codehaus.activemq.journal.impl.RecordHeader
 
RECOVER - Static variable in interface org.codehaus.activemq.message.TransactionType
Recover a transaction
REDELIVERED_INDEX - Static variable in class org.codehaus.activemq.message.ActiveMQMessage
 
REPLY_TO_INDEX - Static variable in class org.codehaus.activemq.message.ActiveMQMessage
 
RESPONSE_RECEIPT_INFO - Static variable in interface org.codehaus.activemq.message.Packet
A receipt with an Object reponse.
ROLLBACK - Static variable in interface org.codehaus.activemq.message.TransactionType
Rollback a transaction
RangeStatisticImpl - class org.codehaus.activemq.management.RangeStatisticImpl.
A range statistic implementation
RangeStatisticImpl(String, String, String) - Constructor for class org.codehaus.activemq.management.RangeStatisticImpl
 
ReInit(InputStream) - Method in class org.codehaus.activemq.selector.SelectorParser
 
ReInit(Reader) - Method in class org.codehaus.activemq.selector.SelectorParser
 
ReInit(SelectorParserTokenManager) - Method in class org.codehaus.activemq.selector.SelectorParser
 
ReInit(SimpleCharStream) - Method in class org.codehaus.activemq.selector.SelectorParserTokenManager
 
ReInit(SimpleCharStream, int) - Method in class org.codehaus.activemq.selector.SelectorParserTokenManager
 
ReInit(Reader, int, int, int) - Method in class org.codehaus.activemq.selector.SimpleCharStream
 
ReInit(Reader, int, int) - Method in class org.codehaus.activemq.selector.SimpleCharStream
 
ReInit(Reader) - Method in class org.codehaus.activemq.selector.SimpleCharStream
 
ReInit(InputStream, int, int, int) - Method in class org.codehaus.activemq.selector.SimpleCharStream
 
ReInit(InputStream) - Method in class org.codehaus.activemq.selector.SimpleCharStream
 
ReInit(InputStream, int, int) - Method in class org.codehaus.activemq.selector.SimpleCharStream
 
ReadOnlyContext - class org.codehaus.activemq.jndi.ReadOnlyContext.
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.codehaus.activemq.jndi.ReadOnlyContext
 
ReadOnlyContext(Hashtable) - Constructor for class org.codehaus.activemq.jndi.ReadOnlyContext
 
ReadOnlyContext(Hashtable, Map) - Constructor for class org.codehaus.activemq.jndi.ReadOnlyContext
 
ReadOnlyContext(ReadOnlyContext, Hashtable) - Constructor for class org.codehaus.activemq.jndi.ReadOnlyContext
 
Receipt - class org.codehaus.activemq.message.Receipt.
Sent in receipt of a Packet
Receipt() - Constructor for class org.codehaus.activemq.message.Receipt
 
ReceiptHolder - class org.codehaus.activemq.message.ReceiptHolder.
ReceiptHolder is a utility class used for waiting for receipts from Packets sent to the broker
ReceiptHolder() - Constructor for class org.codehaus.activemq.message.ReceiptHolder
Construct a receipt holder
ReceiptReader - class org.codehaus.activemq.message.ReceiptReader.
Reads a ConsumerInfo object from a Stream
ReceiptReader() - Constructor for class org.codehaus.activemq.message.ReceiptReader
 
ReceiptWriter - class org.codehaus.activemq.message.ReceiptWriter.
Writes a ConsumerInfo object to a Stream
ReceiptWriter() - Constructor for class org.codehaus.activemq.message.ReceiptWriter
 
Record - class org.codehaus.activemq.journal.impl.Record.
Serializes/Deserializes data records.
Record(RecordHeader, byte[]) - Constructor for class org.codehaus.activemq.journal.impl.Record
 
Record(long, byte, byte[], Mark) - Constructor for class org.codehaus.activemq.journal.impl.Record
 
RecordFooter - class org.codehaus.activemq.journal.impl.RecordFooter.
Serializes/Deserializes record header information.
RecordFooter() - Constructor for class org.codehaus.activemq.journal.impl.RecordFooter
 
RecordHeader - class org.codehaus.activemq.journal.impl.RecordHeader.
Serializes/Deserializes record header information.
RecordHeader() - Constructor for class org.codehaus.activemq.journal.impl.RecordHeader
 
RecordLocation - interface org.codehaus.activemq.journal.RecordLocation.
A RecordLocation is used to locate data records that have been logged to a Journal via the Journal.put() method call.
RecordLocationImpl - class org.codehaus.activemq.journal.impl.RecordLocationImpl.
Defines a where a record can be located in the Journal.
RecordLocationImpl(byte, byte, int, long) - Constructor for class org.codehaus.activemq.journal.impl.RecordLocationImpl
 
RecordLocationImpl(byte, byte, int) - Constructor for class org.codehaus.activemq.journal.impl.RecordLocationImpl
 
RedeliverMessageTransactionTask - class org.codehaus.activemq.service.impl.RedeliverMessageTransactionTask.
Acknowledge a message as part of XA
RedeliverMessageTransactionTask(BrokerClient, MessageAck) - Constructor for class org.codehaus.activemq.service.impl.RedeliverMessageTransactionTask
 
RedeliveryPolicy - class org.codehaus.activemq.service.RedeliveryPolicy.
Represents the redelivery policy which is used when a rollback() occurs (either JMS or XA).
RedeliveryPolicy() - Constructor for class org.codehaus.activemq.service.RedeliveryPolicy
 
ReliableTransportChannel - class org.codehaus.activemq.transport.reliable.ReliableTransportChannel.
A Compsite implementation of a TransportChannel
ReliableTransportChannel(WireFormat) - Constructor for class org.codehaus.activemq.transport.reliable.ReliableTransportChannel
Construct this transport
ReliableTransportChannel(WireFormat, List) - Constructor for class org.codehaus.activemq.transport.reliable.ReliableTransportChannel
Construct this transport
ReliableTransportChannelFactory - class org.codehaus.activemq.transport.reliable.ReliableTransportChannelFactory.
A Reliable implementation of a TransportChannelFactory
ReliableTransportChannelFactory() - Constructor for class org.codehaus.activemq.transport.reliable.ReliableTransportChannelFactory
 
Resettable - interface org.codehaus.activemq.management.Resettable.
Represents some statistic that is capable of being reset
ResponseReceipt - class org.codehaus.activemq.message.ResponseReceipt.
A receipt that also carries a reponse object.
ResponseReceipt() - Constructor for class org.codehaus.activemq.message.ResponseReceipt
 
ResponseReceiptReader - class org.codehaus.activemq.message.ResponseReceiptReader.
Reads a ConsumerInfo object from a Stream
ResponseReceiptReader() - Constructor for class org.codehaus.activemq.message.ResponseReceiptReader
 
ResponseReceiptWriter - class org.codehaus.activemq.message.ResponseReceiptWriter.
Writes a ConsumerInfo object to a Stream
ResponseReceiptWriter() - Constructor for class org.codehaus.activemq.message.ResponseReceiptWriter
 
randomizeURIs(List) - Method in class org.codehaus.activemq.transport.composite.CompositeTransportChannelFactory
 
randomizeURIs(List) - Method in class org.codehaus.activemq.transport.reliable.ReliableTransportChannelFactory
 
read(RecordLocation) - Method in interface org.codehaus.activemq.journal.Journal
Reads a previously written record from the journal.
read(RecordLocation) - Method in class org.codehaus.activemq.journal.JournalStatsFilter
 
read(RecordLocation) - Method in class org.codehaus.activemq.journal.howl.HowlJournal
 
read(RecordLocation) - Method in class org.codehaus.activemq.journal.impl.JournalImpl
 
read(RecordLocationImpl) - Method in class org.codehaus.activemq.journal.impl.LogFileManager
 
read(byte[]) - Method in class org.codehaus.activemq.journal.impl.Segment
 
read(DataInput) - Static method in class org.codehaus.activemq.message.ActiveMQXid
Reads the Xid from a stream
read() - Method in class org.codehaus.activemq.message.util.DataContainer
read a block of data from the container
read() - Method in class org.codehaus.activemq.message.util.FileDataBlock
read next chunk of data
read() - Method in class org.codehaus.activemq.message.util.WireByteArrayInputStream
Reads the next byte of data from this input stream.
read(byte[], int, int) - Method in class org.codehaus.activemq.message.util.WireByteArrayInputStream
Reads up to len bytes of data into an array of bytes from this input stream.
readBody(DataInput) - Method in class org.codehaus.activemq.message.ActiveMQMapMessage
 
readBody(DataInput) - Method in class org.codehaus.activemq.message.ActiveMQMessage
Used to help build the body from an input stream
readBody(DataInput) - Method in class org.codehaus.activemq.message.ActiveMQObjectMessage
Used to help build the body from an input stream
readBody(DataInput) - Method in class org.codehaus.activemq.message.ActiveMQTextMessage
Used to help build the body from an input stream
readBoolean() - Method in class org.codehaus.activemq.message.ActiveMQBytesMessage
Reads a boolean from the bytes message stream.
readBoolean() - Method in class org.codehaus.activemq.message.ActiveMQStreamMessage
Reads a boolean from the stream message.
readByte() - Method in class org.codehaus.activemq.message.ActiveMQBytesMessage
Reads a signed 8-bit value from the bytes message stream.
readByte() - Method in class org.codehaus.activemq.message.ActiveMQStreamMessage
Reads a byte value from the stream message.
readBytes(byte[]) - Method in class org.codehaus.activemq.message.ActiveMQBytesMessage
Reads a byte array from the bytes message stream.
readBytes(byte[], int) - Method in class org.codehaus.activemq.message.ActiveMQBytesMessage
Reads a portion of the bytes message stream.
readBytes(byte[]) - Method in class org.codehaus.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.codehaus.activemq.message.ActiveMQXid
 
readChar() - Method in class org.codehaus.activemq.message.ActiveMQBytesMessage
Reads a Unicode character value from the bytes message stream.
readChar() - Method in class org.codehaus.activemq.message.ActiveMQStreamMessage
Reads a Unicode character value from the stream message.
readChar() - Method in class org.codehaus.activemq.selector.SimpleCharStream
 
readData(int, int) - Method in class org.codehaus.activemq.journal.impl.LogFile
 
readDouble() - Method in class org.codehaus.activemq.message.ActiveMQBytesMessage
Reads a double from the bytes message stream.
readDouble() - Method in class org.codehaus.activemq.message.ActiveMQStreamMessage
Reads a double from the stream message.
readExternal(byte[]) - Method in class org.codehaus.activemq.journal.impl.Mark
 
readExternal(ObjectInput) - Method in class org.codehaus.activemq.message.ActiveMQXid
 
readExternal(ObjectInput) - Method in class org.codehaus.activemq.message.PacketFacade
 
readExternal(ObjectInput) - Method in class org.codehaus.activemq.service.SubscriberEntry
 
readExternal(ObjectInput) - Method in class org.codehaus.activemq.service.impl.AbstractTransaction
 
readExternal(ObjectInput) - Method in class org.codehaus.activemq.service.impl.MessageEntry
 
readExternal(ObjectInput) - Method in class org.codehaus.activemq.service.impl.PacketTransactionTask
 
readExternal(ObjectInput) - Method in class org.codehaus.activemq.service.impl.XATransactionCommand
 
readExternal(ObjectInput) - Method in class org.codehaus.activemq.web.WebClient
 
readFloat() - Method in class org.codehaus.activemq.message.ActiveMQBytesMessage
Reads a float from the bytes message stream.
readFloat() - Method in class org.codehaus.activemq.message.ActiveMQStreamMessage
Reads a float from the stream message.
readFromStream(DataInput) - Static method in class org.codehaus.activemq.message.ActiveMQDestination
Read an ActiveMQDestination from a Stream
readFromStream(DataInput) - Method in class org.codehaus.activemq.util.BitArray
read the bits from an input stream
readInt() - Method in class org.codehaus.activemq.message.ActiveMQBytesMessage
Reads a signed 32-bit integer from the bytes message stream.
readInt() - Method in class org.codehaus.activemq.message.ActiveMQStreamMessage
Reads a 32-bit integer from the stream message.
readLong() - Method in class org.codehaus.activemq.message.ActiveMQBytesMessage
Reads a signed 64-bit integer from the bytes message stream.
readLong() - Method in class org.codehaus.activemq.message.ActiveMQStreamMessage
Reads a 64-bit integer from the stream message.
readMapProperties(DataInput) - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
readNullableUTF(ObjectInput) - Static method in class org.codehaus.activemq.service.SubscriberEntry
 
readObject(DataInput) - Method in class org.codehaus.activemq.message.AbstractPacketReader
;
readObject() - Method in class org.codehaus.activemq.message.ActiveMQStreamMessage
Reads an object from the stream message.
readOnlyMessage - Variable in class org.codehaus.activemq.message.ActiveMQMessage
readOnlyMessage denotes if the message is read only
readPacket(DataInput) - Method in class org.codehaus.activemq.message.DefaultWireFormat
 
readPacket(int, DataInput) - Method in class org.codehaus.activemq.message.DefaultWireFormat
 
readPacket(DataInput, PacketReader) - Method in class org.codehaus.activemq.message.DefaultWireFormat
 
readPacket(DataInput) - Method in class org.codehaus.activemq.message.WireFormat
Reads a packet from the given input stream
readPacket(int, DataInput) - Method in class org.codehaus.activemq.message.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 class org.codehaus.activemq.message.WireFormat
Read a packet from a Datagram packet from the given channelID.
readPacket(ObjectInput) - Static method in class org.codehaus.activemq.service.impl.PacketTransactionTask
 
readPacket(LogRecord, QueueMessageContainer) - Method in class org.codehaus.activemq.store.howl.HowlMessageStore
 
readPacket(RecordLocation) - Method in class org.codehaus.activemq.store.journal.JournalPersistenceAdapter
 
readPacket(DataInput) - Method in class org.codehaus.activemq.transport.jabber.JabberWireFormat
 
readPacket(int, DataInput) - Method in class org.codehaus.activemq.transport.jabber.JabberWireFormat
 
readPacket(DataInput) - Method in class org.codehaus.activemq.transport.xstream.XStreamWireFormat
 
readPacket(int, DataInput) - Method in class org.codehaus.activemq.transport.xstream.XStreamWireFormat
 
readPacketFromByteArray(byte[]) - Method in class org.codehaus.activemq.message.AbstractPacketReader
Deserailizes a Packet from a byte array
readPacketFromByteArray(byte[]) - Method in interface org.codehaus.activemq.message.PacketReader
Deserailizes a Packet from a byte array
readRecordFooter(DataInput) - Method in class org.codehaus.activemq.journal.impl.RecordFooter
 
readRecordHeader(DataInput) - Method in class org.codehaus.activemq.journal.impl.RecordHeader
 
readRecordHeader(RecordHeader) - Method in class org.codehaus.activemq.journal.impl.Segment
 
readRecordLocation(RecordLocationImpl) - Method in class org.codehaus.activemq.journal.impl.LogFile
 
readRequestBody(HttpServletRequest) - Method in class org.codehaus.activemq.transport.http.HttpTunnelServlet
 
readShort() - Method in class org.codehaus.activemq.message.ActiveMQBytesMessage
Reads a signed 16-bit number from the bytes message stream.
readShort() - Method in class org.codehaus.activemq.message.ActiveMQStreamMessage
Reads a 16-bit integer from the stream message.
readState(DataInput) - Method in class org.codehaus.activemq.message.ActiveMQXid
 
readString() - Method in class org.codehaus.activemq.message.ActiveMQStreamMessage
Reads a String from the stream message.
readTask(ObjectInput) - Method in class org.codehaus.activemq.service.impl.AbstractTransaction
 
readTask(ObjectInput) - Static method in class org.codehaus.activemq.service.impl.PacketTransactionTask
 
readTaskList(ObjectInput) - Method in class org.codehaus.activemq.service.impl.AbstractTransaction
 
readUTF(DataInput) - Method in class org.codehaus.activemq.message.AbstractPacketReader
pointless method - but mirrors writer
readUTF() - Method in class org.codehaus.activemq.message.ActiveMQBytesMessage
Reads a string that has been encoded using a modified UTF-8 format from the bytes message stream.
readUnsignedByte() - Method in class org.codehaus.activemq.message.ActiveMQBytesMessage
Reads an unsigned 8-bit number from the bytes message stream.
readUnsignedShort() - Method in class org.codehaus.activemq.message.ActiveMQBytesMessage
Reads an unsigned 16-bit number from the bytes message stream.
rebind(Name, Object) - Method in class org.codehaus.activemq.jndi.ReadOnlyContext
 
rebind(String, Object) - Method in class org.codehaus.activemq.jndi.ReadOnlyContext
 
receive(long) - Method in class org.codehaus.activemq.ActiveMQConnectionConsumer
Receives the next message that arrives within the specified timeout interval.
receive() - Method in class org.codehaus.activemq.ActiveMQMessageConsumer
Receives the next message produced for this message consumer.
receive(long) - Method in class org.codehaus.activemq.ActiveMQMessageConsumer
Receives the next message that arrives within the specified timeout interval.
receiveNoWait() - Method in class org.codehaus.activemq.ActiveMQMessageConsumer
Receives the next message if one is immediately available.
recordType - Variable in class org.codehaus.activemq.journal.impl.RecordHeader
 
recover() - Method in class org.codehaus.activemq.ActiveMQSession
Stops message delivery in this session, and restarts message delivery with the oldest unacknowledged message.
recover(int) - Method in class org.codehaus.activemq.ActiveMQXASession
 
recover() - Method in class org.codehaus.activemq.ra.JMSSessionProxy
 
recover(QueueMessageContainer) - Method in interface org.codehaus.activemq.store.MessageStore
Recover any messages to be delivered onto the dispatch queue.
recover(QueueMessageContainer) - Method in class org.codehaus.activemq.store.bdb.BDbMessageStore
 
recover(QueueMessageContainer) - Method in class org.codehaus.activemq.store.bdbn.BDbMessageStore
 
recover(QueueMessageContainer) - Method in class org.codehaus.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(QueueMessageContainer) - Method in class org.codehaus.activemq.store.howl.HowlMessageStore
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(QueueMessageContainer) - Method in class org.codehaus.activemq.store.jdbc.JDBCMessageStore
 
recover(QueueMessageContainer) - Method in class org.codehaus.activemq.store.jdbm.JdbmMessageStore
 
recover(QueueMessageContainer) - Method in class org.codehaus.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(QueueMessageContainer) - Method in class org.codehaus.activemq.store.vm.VMMessageStore
 
recoverMessageToBeDelivered(MessageIdentity) - Method in interface org.codehaus.activemq.service.QueueMessageContainer
Invoked during the recovery to add the given message to the end of the messages to be delivered.
recoverMessageToBeDelivered(MessageIdentity) - Method in class org.codehaus.activemq.service.impl.DurableQueueMessageContainer
 
recoverSubscription(Subscription) - Method in interface org.codehaus.activemq.service.TopicMessageContainer
A durable subscription has started so recovery any messages that are required.
recoverSubscription(Subscription) - Method in class org.codehaus.activemq.service.impl.DurableTopicMessageContainer
 
recoverSubscription(Subscription, MessageIdentity) - Method in interface org.codehaus.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(Subscription, MessageIdentity) - Method in class org.codehaus.activemq.store.bdb.BDbTopicMessageStore
 
recoverSubscription(Subscription, MessageIdentity) - Method in class org.codehaus.activemq.store.bdbn.BDbTopicMessageStore
 
recoverSubscription(Subscription, MessageIdentity) - Method in class org.codehaus.activemq.store.cache.CacheTopicMessageStore
 
recoverSubscription(Subscription, MessageIdentity) - Method in class org.codehaus.activemq.store.jdbc.JDBCTopicMessageStore
 
recoverSubscription(Subscription, MessageIdentity) - Method in class org.codehaus.activemq.store.jdbm.JdbmTopicMessageStore
 
recoverSubscription(Subscription, MessageIdentity) - Method in class org.codehaus.activemq.store.vm.VMTopicMessageStore
 
recoverSubscriptions(Subscription) - Method in class org.codehaus.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
redeliverMessage(BrokerClient, MessageAck) - Method in interface org.codehaus.activemq.broker.Broker
Called after a rollback of a JMS transaction to redeliver the message to the consumers dispatch queue
redeliverMessage(BrokerClient, MessageAck) - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
redeliverMessage(BrokerClient, MessageAck) - Method in interface org.codehaus.activemq.service.MessageContainerManager
Called after a rollback of a JMS transaction to redeliver the message to the consumers dispatch queue
redeliverMessage(MessageContainer, MessageAck) - Method in interface org.codehaus.activemq.service.Subscription
Forces the given message to be redelivered
redeliverMessage(BrokerClient, MessageAck) - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageManager
 
redeliverMessage(BrokerClient, MessageAck) - Method in class org.codehaus.activemq.service.boundedvm.TransientTopicBoundedMessageManager
 
redeliverMessage(BrokerClient, MessageAck) - Method in class org.codehaus.activemq.service.impl.DurableQueueMessageContainerManager
 
redeliverMessage(BrokerClient, MessageAck) - Method in class org.codehaus.activemq.service.impl.DurableTopicMessageContainerManager
 
redeliverMessage(MessageContainer, MessageAck) - Method in class org.codehaus.activemq.service.impl.DurableTopicSubscription
 
redeliverMessage(BrokerClient, MessageAck) - Method in class org.codehaus.activemq.service.impl.ProxyMessageContainerManager
 
redeliverMessage(MessageContainer, MessageAck) - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
 
redeliverUnacknowledgedMessages() - Method in class org.codehaus.activemq.ActiveMQSession
 
redeliverUnacknowledgedMessages(boolean) - Method in class org.codehaus.activemq.ActiveMQSession
 
refCount - Variable in class org.codehaus.activemq.filter.MultiExpressionEvaluator.CacheExpression
 
register(MessageContainerManager) - Method in interface org.codehaus.activemq.service.Dispatcher
Register the MessageContainerManager for the Dispatcher
register(MessageContainerManager) - Method in class org.codehaus.activemq.service.impl.DispatchWorker
Register the MessageContainerManager for the Dispatcher
register(MessageContainerManager) - Method in class org.codehaus.activemq.service.impl.DispatcherImpl
Register the MessageContainerManager for the Dispatcher
registerBeanDefinitions(Document, Resource) - Method in class org.codehaus.activemq.spring.ActiveMQBeanDefinitionReader
 
registerBroker(String, BrokerConnector) - Static method in class org.codehaus.activemq.ActiveMQConnectionFactory
 
registerClient(BrokerClient, ConnectionInfo) - Method in interface org.codehaus.activemq.broker.BrokerConnector
Register a Broker Client
registerClient(BrokerClient, ConnectionInfo) - Method in class org.codehaus.activemq.broker.impl.BrokerConnectorImpl
Register a Broker Client
registerConnection(BrokerClient, ConnectionInfo) - Method in interface org.codehaus.activemq.broker.BrokerContainer
registers a new Connection
registerConnection(BrokerClient, ConnectionInfo) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
registers a new Connection
registerConnector(String, BrokerConnector) - Method in class org.codehaus.activemq.broker.BrokerContext
 
registerContainer(String, BrokerContainer) - Method in class org.codehaus.activemq.broker.BrokerContext
 
registerMessageConsumer(BrokerClient, ConsumerInfo) - Method in interface org.codehaus.activemq.broker.BrokerConnector
Registers a MessageConsumer
registerMessageConsumer(BrokerClient, ConsumerInfo) - Method in interface org.codehaus.activemq.broker.BrokerContainer
Registers a MessageConsumer
registerMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.codehaus.activemq.broker.impl.BrokerConnectorImpl
Registers a MessageConsumer
registerMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
Registers a MessageConsumer
registerMessageInterest(MessageIdentity) - Method in interface org.codehaus.activemq.service.MessageContainer
Register that a consumer will be interested in this message
registerMessageInterest(MessageIdentity) - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
 
registerMessageInterest(MessageIdentity) - Method in class org.codehaus.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
 
registerMessageInterest(MessageIdentity) - Method in class org.codehaus.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.codehaus.activemq.service.impl.DurableTopicMessageContainer
 
registerMessageProducer(BrokerClient, ProducerInfo) - Method in interface org.codehaus.activemq.broker.BrokerConnector
Registers a MessageProducer
registerMessageProducer(BrokerClient, ProducerInfo) - Method in interface org.codehaus.activemq.broker.BrokerContainer
Registers a MessageProducer
registerMessageProducer(BrokerClient, ProducerInfo) - Method in class org.codehaus.activemq.broker.impl.BrokerConnectorImpl
Registers a MessageProducer
registerMessageProducer(BrokerClient, ProducerInfo) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
Registers a MessageProducer
registerService(String, Map) - Method in interface org.codehaus.activemq.transport.DiscoveryAgent
 
registerService(String, Map) - Method in class org.codehaus.activemq.transport.zeroconf.ZeroconfDiscoveryAgent
 
registerSession(BrokerClient, SessionInfo) - Method in interface org.codehaus.activemq.broker.BrokerConnector
Register a client-side Session (used for Monitoring)
registerSession(BrokerClient, SessionInfo) - Method in interface org.codehaus.activemq.broker.BrokerContainer
Register a client-side Session (used for Monitoring)
registerSession(BrokerClient, SessionInfo) - Method in class org.codehaus.activemq.broker.impl.BrokerConnectorImpl
Register a client-side Session (used for Monitoring)
registerSession(BrokerClient, SessionInfo) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
Register a client-side Session (used for Monitoring)
reinitialize() - Method in class org.codehaus.activemq.journal.impl.Segment
 
release() - Method in class org.codehaus.activemq.ra.ActiveMQAsfEndpointWorker.ServerSessionImpl
 
release() - Method in class org.codehaus.activemq.ra.ActiveMQPollingEndpointWorker.InboundEndpointWork
 
release() - Method in class org.codehaus.activemq.ra.ActiveMQPollingEndpointWorker
 
remaining() - Method in class org.codehaus.activemq.journal.impl.Record
 
remove(ActiveMQDestination, Object) - Method in class org.codehaus.activemq.filter.DestinationMap
Removes the value from the associated destination
remove(String[], int, Object) - Method in class org.codehaus.activemq.filter.DestinationMapNode
 
remove(Packet) - Method in class org.codehaus.activemq.message.util.MemoryBoundedQueue
Remove a packet from the queue
remove(String) - Method in class org.codehaus.activemq.message.util.MemoryBoundedQueue
Remove a Packet by it's id
remove(Object) - Method in interface org.codehaus.activemq.service.QueueList
Removes the first occurrence of the specified element in this list.
remove(int) - Method in interface org.codehaus.activemq.service.QueueList
Removes the element at the specified position in this list.
remove(QueueListEntry) - Method in interface org.codehaus.activemq.service.QueueList
Remove a DefaultQueueListEntry
remove(Object) - Method in class org.codehaus.activemq.service.impl.DefaultQueueList
 
remove(int) - Method in class org.codehaus.activemq.service.impl.DefaultQueueList
 
remove(QueueListEntry) - Method in class org.codehaus.activemq.service.impl.DefaultQueueList
 
remove(int) - Method in class org.codehaus.activemq.service.impl.QueueListSupport
 
remove(QueueListEntry) - Method in class org.codehaus.activemq.service.impl.QueueListSupport
 
remove(ActiveMQXid) - Method in interface org.codehaus.activemq.store.PreparedTransactionStore
 
remove(ActiveMQXid) - Method in class org.codehaus.activemq.store.bdb.BDbPreparedTransactionStore
 
remove(String) - Method in interface org.codehaus.activemq.store.cache.MessageCache
Remvoes a message from the cache.
remove(String) - Method in class org.codehaus.activemq.store.cache.SimpleMessageCache
Remvoes a message from the cache.
remove(ActiveMQXid) - Method in class org.codehaus.activemq.store.jdbc.JDBCPreparedTransactionStore
 
remove(ActiveMQXid) - Method in class org.codehaus.activemq.store.jdbm.JdbmPreparedTransactionStore
 
remove(ActiveMQXid) - Method in class org.codehaus.activemq.store.vm.VMPreparedTransactionStoreImpl
 
removeActiveSubscription(BrokerClient, Subscription) - Method in interface org.codehaus.activemq.service.Dispatcher
remove an active subscription
removeActiveSubscription(BrokerClient, Subscription) - Method in class org.codehaus.activemq.service.impl.DispatchWorker
remove an active subscription
removeActiveSubscription(BrokerClient, Subscription) - Method in class org.codehaus.activemq.service.impl.DispatcherImpl
remove an active subscription
removeCapacityEventListener(CapacityMonitorEventListener) - Method in class org.codehaus.activemq.capacity.BasicCapacityMonitor
Remove a CapacityMonitorEventListener
removeCapacityEventListener(CapacityMonitorEventListener) - Method in interface org.codehaus.activemq.capacity.CapacityMonitor
Remove a CapacityMonitorEventListener
removeCapacityEventListener(CapacityMonitorEventListener) - Method in class org.codehaus.activemq.capacity.DelegateCapacityMonitor
Remove a CapacityEventListener
removeChannel(String, Map) - Method in class org.codehaus.activemq.transport.DiscoveryNetworkConnector
 
removeClient(BrokerClient, ConnectionInfo) - Method in interface org.codehaus.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.codehaus.activemq.broker.impl.BrokerConnectorImpl
 
removeClient(BrokerClient, ConnectionInfo) - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
removeClient(TransportChannel) - Method in interface org.codehaus.activemq.transport.TransportChannelListener
Called when a channel has been closed and removed from a server
removeConnection(ActiveMQConnection) - Method in class org.codehaus.activemq.management.JMSStatsImpl
 
removeConnectionConsumer(ActiveMQConnectionConsumer) - Method in class org.codehaus.activemq.ActiveMQConnection
Remove a ConnectionConsumer
removeConnectionEventListener(ConnectionEventListener) - Method in class org.codehaus.activemq.ra.ActiveMQManagedConnection
 
removeConnector(BrokerConnector) - Method in interface org.codehaus.activemq.broker.BrokerContainer
Called when a connector is removed to this container
removeConnector(BrokerConnector) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
 
removeConsumer(ActiveMQMessageConsumer) - Method in class org.codehaus.activemq.ActiveMQSession
 
removeConsumer(ConsumerInfo) - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
Remove a consumer
removeConsumer(ConsumerInfo) - Method in class org.codehaus.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
Remove a consumer
removeConsumerInfoListener(ConsumerInfoListener) - Method in interface org.codehaus.activemq.broker.Broker
Remove a ConsumerInfoListener from the Broker
removeConsumerInfoListener(ConsumerInfoListener) - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
Remove a ConsumerInfoListener from the Broker
removeEldestEntry(Map.Entry) - Method in class org.codehaus.activemq.util.LRUCache
 
removeEventListner(String, MultiExpressionEvaluator.ExpressionListener) - Method in class org.codehaus.activemq.filter.MultiExpressionEvaluator
Removes an ExpressionListener from receiving the results of a given evaluation.
removeExpiredMessages() - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
 
removeFirst() - Method in interface org.codehaus.activemq.service.QueueList
Removes and returns the first element from this list.
removeFirst() - Method in class org.codehaus.activemq.service.impl.DefaultQueueList
remove the first object from the list
removeFirst() - Method in class org.codehaus.activemq.service.impl.QueueListSupport
 
removeFromEnvironment(String) - Method in class org.codehaus.activemq.jndi.ReadOnlyContext
 
removeLast() - Method in interface org.codehaus.activemq.service.QueueList
Removes and returns the last element from this list.
removeLast() - Method in class org.codehaus.activemq.service.impl.DefaultQueueList
remove the last object
removeLast() - Method in class org.codehaus.activemq.service.impl.QueueListSupport
 
removeMemoryBoundedQueue(String) - Method in class org.codehaus.activemq.message.util.MemoryBoundedQueueManager
 
removeMessage(MessageIdentity, MessageAck) - Method in interface org.codehaus.activemq.store.MessageStore
 
removeMessage(MessageIdentity, MessageAck) - Method in class org.codehaus.activemq.store.bdb.BDbMessageStore
 
removeMessage(MessageIdentity, MessageAck) - Method in class org.codehaus.activemq.store.bdbn.BDbMessageStore
 
removeMessage(MessageIdentity, MessageAck) - Method in class org.codehaus.activemq.store.cache.CacheMessageStore
Remove the meessage to the long term store and remove it from the cache.
removeMessage(MessageIdentity, MessageAck) - Method in class org.codehaus.activemq.store.howl.HowlMessageStore
Removes can be done in any order so we only synchronize on the cache and checkpointStore
removeMessage(MessageIdentity, MessageAck) - Method in class org.codehaus.activemq.store.jdbc.JDBCMessageStore
 
removeMessage(MessageIdentity, MessageAck) - Method in class org.codehaus.activemq.store.jdbm.JdbmMessageStore
 
removeMessage(MessageIdentity, MessageAck) - Method in class org.codehaus.activemq.store.journal.JournalMessageStore
 
removeMessage(MessageIdentity, MessageAck) - Method in class org.codehaus.activemq.store.vm.VMMessageStore
 
removeMessageConsumer(BrokerClient, ConsumerInfo) - Method in interface org.codehaus.activemq.broker.Broker
remove an active message consumer
removeMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
remove an active message consumer
removeMessageConsumer(BrokerClient, ConsumerInfo) - Method in interface org.codehaus.activemq.service.MessageContainerManager
 
removeMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageManager
 
removeMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.codehaus.activemq.service.boundedvm.TransientTopicBoundedMessageManager
 
removeMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.codehaus.activemq.service.impl.DurableQueueMessageContainerManager
 
removeMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.codehaus.activemq.service.impl.DurableTopicMessageContainerManager
 
removeMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.codehaus.activemq.service.impl.ProxyMessageContainerManager
 
removeMessageConsumer(BrokerClient, ConsumerInfo) - Method in class org.codehaus.activemq.service.impl.TransientTopicMessageContainerManager
 
removeMessageDispatcher(ActiveMQMessageDispatcher) - Method in class org.codehaus.activemq.ActiveMQConnection
Remove a Message dispatcher
removeMessageProducer(BrokerClient, ProducerInfo) - Method in interface org.codehaus.activemq.broker.Broker
Removes a producer
removeMessageProducer(BrokerClient, ProducerInfo) - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
removeNetworkChannel(NetworkChannel) - Method in class org.codehaus.activemq.transport.NetworkConnector
Removes a network channel
removeNetworkConnector(NetworkConnector) - Method in interface org.codehaus.activemq.broker.BrokerContainer
Removes the given network connector
removeNetworkConnector(NetworkConnector) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
 
removeNode(QueueListSupport.Node) - Method in class org.codehaus.activemq.service.impl.QueueListSupport
 
removeProducer(ActiveMQMessageProducer) - Method in class org.codehaus.activemq.ActiveMQSession
 
removeService(DiscoveryEvent) - Method in interface org.codehaus.activemq.transport.DiscoveryListener
 
removeService(DiscoveryEvent) - Method in class org.codehaus.activemq.transport.DiscoveryNetworkConnector
 
removeService(DiscoveryEvent) - Method in class org.codehaus.activemq.transport.DiscoveryTransportChannel
 
removeService(JmDNS, String, String) - Method in class org.codehaus.activemq.transport.zeroconf.ZeroconfDiscoveryAgent
 
removeSession(ActiveMQSession) - Method in class org.codehaus.activemq.ActiveMQConnection
Used interanlly for removing Sessions from a Connection
removeSubscription(String) - Method in interface org.codehaus.activemq.service.SubscriptionContainer
 
removeSubscription(String) - Method in class org.codehaus.activemq.service.impl.SubscriptionContainerImpl
 
removeTransportStatusEventListener(TransportStatusEventListener) - Method in interface org.codehaus.activemq.transport.TransportChannel
Remove a listener for changes in a channels status
removeTransportStatusEventListener(TransportStatusEventListener) - Method in class org.codehaus.activemq.transport.TransportChannelSupport
Remove a listener for changes in a channels status
rename(Name, Name) - Method in class org.codehaus.activemq.jndi.ReadOnlyContext
 
rename(String, String) - Method in class org.codehaus.activemq.jndi.ReadOnlyContext
 
requiresEmbeddedBroker() - Method in interface org.codehaus.activemq.transport.TransportChannelFactory
Does this channel require an embedded broker to perform such as VM or multicast based transports
requiresEmbeddedBroker() - Method in class org.codehaus.activemq.transport.composite.CompositeTransportChannelFactory
 
requiresEmbeddedBroker() - Method in class org.codehaus.activemq.transport.ember.EmberTransportChannelFactory
 
requiresEmbeddedBroker() - Method in class org.codehaus.activemq.transport.gnet.GTransportChannelFactory
 
requiresEmbeddedBroker() - Method in class org.codehaus.activemq.transport.http.HttpTransportChannelFactory
 
requiresEmbeddedBroker() - Method in class org.codehaus.activemq.transport.jgroups.JGroupsTransportChannelFactory
 
requiresEmbeddedBroker() - Method in class org.codehaus.activemq.transport.jrms.JRMSTransportChannelFactory
 
requiresEmbeddedBroker() - Method in class org.codehaus.activemq.transport.jxta.JxtaTransportChannelFactory
 
requiresEmbeddedBroker() - Method in class org.codehaus.activemq.transport.multicast.MulticastTransportChannelFactory
 
requiresEmbeddedBroker() - Method in class org.codehaus.activemq.transport.tcp.TcpTransportChannelFactory
 
requiresEmbeddedBroker() - Method in class org.codehaus.activemq.transport.udp.UdpTransportChannelFactory
 
requiresEmbeddedBroker() - Method in class org.codehaus.activemq.transport.vm.VmTransportChannelFactory
 
requiresLayout() - Method in class org.codehaus.activemq.util.JmsLogAppenderSupport
 
reset() - Method in class org.codehaus.activemq.journal.JournalStatsFilter
Resets the stats sample.
reset() - Method in class org.codehaus.activemq.management.CountStatisticImpl
 
reset() - Method in class org.codehaus.activemq.management.RangeStatisticImpl
 
reset() - Method in interface org.codehaus.activemq.management.Resettable
Reset the statistic
reset() - Method in class org.codehaus.activemq.management.StatisticImpl
 
reset() - Method in class org.codehaus.activemq.management.StatsImpl
 
reset() - Method in class org.codehaus.activemq.management.TimeStatisticImpl
 
reset() - Method in class org.codehaus.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.codehaus.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.codehaus.activemq.message.util.WireByteArrayOutputStream
reset the output stream
reset() - Method in interface org.codehaus.activemq.service.QueueMessageContainer
called to reset dispatch pointers if a new Message Consumer joins
reset() - Method in interface org.codehaus.activemq.service.Subscription
Called when an active message consumer has closed.
reset() - Method in class org.codehaus.activemq.service.impl.DurableQueueMessageContainer
called to reset dispatch pointers if a new Message Consumer joins
reset() - Method in class org.codehaus.activemq.service.impl.MessagePointer
Reset default states for this MessagePointer
reset() - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
Called when an active subscriber has closed.
reset() - Method in class org.codehaus.activemq.util.BitArray
reset all the bit values to false
resolveEntity(String, String) - Method in class org.codehaus.activemq.spring.ActiveMQDtdResolver
 
resolveService(JmDNS, String, String, ServiceInfo) - Method in class org.codehaus.activemq.transport.zeroconf.ZeroconfDiscoveryAgent
 
restart(byte[], int, int) - Method in class org.codehaus.activemq.message.util.WireByteArrayInputStream
reset the WireByteArrayInputStream to use an new byte array
restart(byte[]) - Method in class org.codehaus.activemq.message.util.WireByteArrayInputStream
reset the WireByteArrayInputStream to use an new byte array
restart(int) - Method in class org.codehaus.activemq.message.util.WireByteArrayOutputStream
start using a fresh byte array
restart() - Method in class org.codehaus.activemq.message.util.WireByteArrayOutputStream
start using a fresh byte array
returnByteBuffer(ByteBuffer) - Method in class org.codehaus.activemq.journal.impl.ByteBufferPool
Returns a ByteBuffer to the pool.
returnConnection(Connection) - Method in class org.codehaus.activemq.store.jdbc.JDBCPersistenceAdapter
 
returnMessage(MessageIdentity) - Method in interface org.codehaus.activemq.service.QueueMessageContainer
After a poll() on the Container, if a message can't be dispatched, it is returned
returnMessage(MessageIdentity) - Method in class org.codehaus.activemq.service.impl.DurableQueueMessageContainer
 
returnObject(Object) - Method in class org.codehaus.activemq.ra.CircularQueue
 
returnToPool(ActiveMQAsfEndpointWorker.ServerSessionImpl) - Method in class org.codehaus.activemq.ra.ActiveMQAsfEndpointWorker.ServerSessionPoolImpl
 
right - Variable in class org.codehaus.activemq.filter.BinaryExpression
 
right - Variable in class org.codehaus.activemq.filter.UnaryExpression
 
rollback() - Method in class org.codehaus.activemq.ActiveMQSession
Rolls back any messages done in this transaction and releases any locks currently held.
rollback() - Method in class org.codehaus.activemq.ActiveMQXASession
 
rollback(Xid) - Method in class org.codehaus.activemq.ActiveMQXASession
 
rollback() - Method in class org.codehaus.activemq.ra.JMSSessionProxy
 
rollback() - Method in interface org.codehaus.activemq.service.Transaction
 
rollback() - Method in class org.codehaus.activemq.service.impl.LocalTransactionCommand
 
rollback() - Method in class org.codehaus.activemq.service.impl.XATransactionCommand
 
rollbackEvent() - Method in interface org.codehaus.activemq.ra.LocalTransactionEventListener
 
rollbackTransaction(BrokerClient, String) - Method in interface org.codehaus.activemq.broker.Broker
rollback a transaction
rollbackTransaction(BrokerClient, ActiveMQXid) - Method in interface org.codehaus.activemq.broker.Broker
 
rollbackTransaction(BrokerClient, String) - Method in interface org.codehaus.activemq.broker.BrokerConnector
Rollback a transacton
rollbackTransaction(BrokerClient, ActiveMQXid) - Method in interface org.codehaus.activemq.broker.BrokerConnector
Rollback an XA transaction.
rollbackTransaction(BrokerClient, String) - Method in interface org.codehaus.activemq.broker.BrokerContainer
Rollback a transacton
rollbackTransaction(BrokerClient, ActiveMQXid) - Method in interface org.codehaus.activemq.broker.BrokerContainer
Rollback an XA transaction.
rollbackTransaction(BrokerClient, String) - Method in class org.codehaus.activemq.broker.impl.BrokerConnectorImpl
Rollback a transacton
rollbackTransaction(BrokerClient, ActiveMQXid) - Method in class org.codehaus.activemq.broker.impl.BrokerConnectorImpl
Rollback an XA transaction.
rollbackTransaction(BrokerClient, String) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
Rollback a transacton
rollbackTransaction(BrokerClient, ActiveMQXid) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
Rollback an XA transaction.
rollbackTransaction(BrokerClient, String) - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
rollback a transaction
rollbackTransaction(BrokerClient, ActiveMQXid) - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
Rollback an XA Transaction.
rollbackTransaction(BrokerClient, String) - Method in interface org.codehaus.activemq.service.MessageContainerManager
A hook when the transaction is about to be rolled back; so discard all outstanding commands that are pending to be written to the Journal
rollbackTransaction(BrokerClient, String) - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageManager
A hook when the transaction is about to be rolled back; so discard all outstanding commands that are pending to be written to the Journal
rollbackTransaction(BrokerClient, String) - Method in class org.codehaus.activemq.service.boundedvm.TransientTopicBoundedMessageManager
A hook when the transaction is about to be rolled back; so discard all outstanding commands that are pending to be written to the Journal
rollbackTransaction(BrokerClient, String) - Method in class org.codehaus.activemq.service.impl.DurableQueueMessageContainerManager
 
rollbackTransaction(BrokerClient, String) - Method in class org.codehaus.activemq.service.impl.DurableTopicMessageContainerManager
 
rollbackTransaction(BrokerClient, String) - Method in class org.codehaus.activemq.service.impl.ProxyMessageContainerManager
 
rollbackTransaction() - Method in interface org.codehaus.activemq.store.PersistenceAdapter
Rollback a persistence transaction
rollbackTransaction() - Method in class org.codehaus.activemq.store.bdb.BDbPersistenceAdapter
 
rollbackTransaction(DbTxn) - Static method in class org.codehaus.activemq.store.bdbn.BDbHelper
Rolls back the transaction, catching all exceptions as we only rollback if we are about to throw an exception anyways
rollbackTransaction() - Method in class org.codehaus.activemq.store.bdbn.BDbPersistenceAdapter
 
rollbackTransaction() - Method in class org.codehaus.activemq.store.cache.CachePersistenceAdapter
 
rollbackTransaction() - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
rollbackTransaction() - Method in class org.codehaus.activemq.store.jdbc.JDBCPersistenceAdapter
 
rollbackTransaction() - Method in class org.codehaus.activemq.store.jdbm.JdbmPersistenceAdapter
 
rollbackTransaction() - Method in class org.codehaus.activemq.store.journal.JournalPersistenceAdapter
 
rollbackTransaction() - Method in class org.codehaus.activemq.store.vm.VMPersistenceAdapter
 
rootExpressions - Variable in class org.codehaus.activemq.filter.MultiExpressionEvaluator
 
rotate() - Method in interface org.codehaus.activemq.service.QueueList
Move the head of the list to the back of the list
rotate() - Method in class org.codehaus.activemq.service.impl.DefaultQueueList
move the first object to the back of the list
rotate() - Method in class org.codehaus.activemq.service.impl.QueueListSupport
 
run() - Method in class org.codehaus.activemq.ActiveMQSession
Optional operation, intended to be used only by Application Servers, not by ordinary JMS clients.
run() - Method in class org.codehaus.activemq.ActiveMQSessionExecutor
implementation of Runnable
run() - Method in class org.codehaus.activemq.ra.ActiveMQAsfEndpointWorker.ServerSessionImpl
 
run() - Method in class org.codehaus.activemq.ra.ActiveMQPollingEndpointWorker.InboundEndpointWork
 
run() - Method in class org.codehaus.activemq.ra.ActiveMQPollingEndpointWorker
The WorkManager has started up and we now need to pull message off the destination and push them to an endpoint.
run() - Method in class org.codehaus.activemq.ra.JMSSessionProxy
 
run() - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
do some dispatching
run() - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageManager
collect expired messages
run() - Method in class org.codehaus.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
do some dispatching
run() - Method in class org.codehaus.activemq.service.impl.DispatchWorker
dispatch messages to active Consumers
run() - Method in class org.codehaus.activemq.transport.http.HttpClientTransportChannel
 
run() - Method in class org.codehaus.activemq.transport.http.HttpTransportChannel
 
run() - Method in class org.codehaus.activemq.transport.jgroups.JGroupsTransportChannel
reads packets from a Socket
run() - Method in class org.codehaus.activemq.transport.jrms.JRMSTransportChannel
reads packets from a Socket
run() - Method in class org.codehaus.activemq.transport.tcp.TcpTransportChannel
reads packets from a Socket
run() - Method in class org.codehaus.activemq.transport.tcp.TcpTransportServerChannel
pull Sockets from the ServerSocket
run() - Method in class org.codehaus.activemq.transport.udp.UdpTransportChannel
reads packets from a Socket
run() - Method in class org.codehaus.activemq.transport.vm.VmTransportChannel
reads packets from a Socket
run(Callback) - Method in class org.codehaus.activemq.util.ExceptionTemplate
 
run(Callback) - Method in class org.codehaus.activemq.util.TransactionTemplate
 
runCounter - Variable in class org.codehaus.activemq.ra.ActiveMQAsfEndpointWorker.ServerSessionImpl
 
runningFlag - Variable in class org.codehaus.activemq.ra.ActiveMQAsfEndpointWorker.ServerSessionImpl
 

S

SEGMENT_HEADER_SIZE - Static variable in class org.codehaus.activemq.journal.impl.Segment
 
SELECTED_CHECKSUM_ALGORITHIM - Static variable in class org.codehaus.activemq.journal.impl.RecordFooter
 
SEPARATOR - Static variable in class org.codehaus.activemq.filter.DestinationPath
 
SESSION_INFO - Static variable in interface org.codehaus.activemq.message.Packet
Session Info message
SET_TX_TIMEOUT - Static variable in interface org.codehaus.activemq.message.TransactionType
Set a the transaction timeout for the RM
SHORT - Static variable in class org.codehaus.activemq.message.ActiveMQMessage
 
SHORT_SIZE - Static variable in class org.codehaus.activemq.util.BitArray
 
SMLCGRandom - class org.codehaus.activemq.transport.reliable.SMLCGRandom.
A Shuffled Multiple Combined Linear Congruential Generator Uses L'Ecuyer's CLCG4 with a Bays-Durham shuffle.
SMLCGRandom() - Constructor for class org.codehaus.activemq.transport.reliable.SMLCGRandom
Creates a new pseudorandom number generator, seeded from the current time.
SMLCGRandom(long) - Constructor for class org.codehaus.activemq.transport.reliable.SMLCGRandom
Creates the generator with the provided seed
SPRING_CLASS_NAME - Static variable in class org.codehaus.activemq.XmlConfigHelper
 
START - Static variable in interface org.codehaus.activemq.message.TransactionType
Start a transaction
START_OF_RECORD - Static variable in class org.codehaus.activemq.journal.impl.RecordHeader
 
START_STATE - Static variable in class org.codehaus.activemq.service.impl.AbstractTransaction
 
STATIC_LEXER_ERROR - Static variable in class org.codehaus.activemq.selector.TokenMgrError
An attempt wass made to create a second instance of a static token manager.
STOPPED - Static variable in class org.codehaus.activemq.transport.TransportStatusEvent
The channel has been STOPPED
STRING - Static variable in class org.codehaus.activemq.message.ActiveMQMessage
 
STRING_LITERAL - Static variable in interface org.codehaus.activemq.selector.SelectorParserConstants
 
SecurityAdapter - interface org.codehaus.activemq.security.SecurityAdapter.
A pluggable strategy to authenticate new connections and authorize the connection and producer and consumer on destinations
Segment - class org.codehaus.activemq.journal.impl.Segment.
Allows read/append access to a segment of a LogFile.
Segment(File, int, byte) - Constructor for class org.codehaus.activemq.journal.impl.Segment
 
SelectorParser - class org.codehaus.activemq.selector.SelectorParser.
JMS Selector Parser generated by JavaCC Do not edit this .java file directly - it is autogenerated from SelectorParser.jj
SelectorParser() - Constructor for class org.codehaus.activemq.selector.SelectorParser
 
SelectorParser(InputStream) - Constructor for class org.codehaus.activemq.selector.SelectorParser
 
SelectorParser(Reader) - Constructor for class org.codehaus.activemq.selector.SelectorParser
 
SelectorParser(SelectorParserTokenManager) - Constructor for class org.codehaus.activemq.selector.SelectorParser
 
SelectorParserConstants - interface org.codehaus.activemq.selector.SelectorParserConstants.
 
SelectorParserTokenManager - class org.codehaus.activemq.selector.SelectorParserTokenManager.
 
SelectorParserTokenManager(SimpleCharStream) - Constructor for class org.codehaus.activemq.selector.SelectorParserTokenManager
 
SelectorParserTokenManager(SimpleCharStream, int) - Constructor for class org.codehaus.activemq.selector.SelectorParserTokenManager
 
SendMessageTransactionTask - class org.codehaus.activemq.service.impl.SendMessageTransactionTask.
Send a message as part of XA
SendMessageTransactionTask(BrokerClient, ActiveMQMessage) - Constructor for class org.codehaus.activemq.service.impl.SendMessageTransactionTask
 
SequenceNumberCreator - class org.codehaus.activemq.store.bdb.SequenceNumberCreator.
 
SequenceNumberCreator() - Constructor for class org.codehaus.activemq.store.bdb.SequenceNumberCreator
 
SerializationHelper - class org.codehaus.activemq.util.SerializationHelper.
 
SerializationHelper() - Constructor for class org.codehaus.activemq.util.SerializationHelper
 
Service - interface org.codehaus.activemq.service.Service.
Service represents some service of some kind with a simple start/stop lifecycle.
SessionInfo - class org.codehaus.activemq.message.SessionInfo.
Denotes an object that can be serialized/deserailized using a Packet Reader/Writer
SessionInfo() - Constructor for class org.codehaus.activemq.message.SessionInfo
 
SessionInfoReader - class org.codehaus.activemq.message.SessionInfoReader.
Reads a ConsumerInfo object from a Stream
SessionInfoReader() - Constructor for class org.codehaus.activemq.message.SessionInfoReader
 
SessionInfoWriter - class org.codehaus.activemq.message.SessionInfoWriter.
Writes a ConsumerInfo object to a Stream
SessionInfoWriter() - Constructor for class org.codehaus.activemq.message.SessionInfoWriter
 
SfTransportChannelFactory - class org.codehaus.activemq.transport.tcp.SfTransportChannelFactory.
A factory of TcpTransportChannelFactory instances using a SocketFactory
SfTransportChannelFactory(SocketFactory) - Constructor for class org.codehaus.activemq.transport.tcp.SfTransportChannelFactory
 
SfTransportServerChannelFactory - class org.codehaus.activemq.transport.tcp.SfTransportServerChannelFactory.
An implementation of TransportServerChannelFactory which uses a ServerSocketFactory to create ServerSocket instances
SfTransportServerChannelFactory(ServerSocketFactory) - Constructor for class org.codehaus.activemq.transport.tcp.SfTransportServerChannelFactory
 
SimpleCachePersistenceAdapter - class org.codehaus.activemq.store.cache.SimpleCachePersistenceAdapter.
Provides a CachePersistenceAdapter that uses a seperate LRU cache for each destination.
SimpleCachePersistenceAdapter() - Constructor for class org.codehaus.activemq.store.cache.SimpleCachePersistenceAdapter
 
SimpleCachePersistenceAdapter(PersistenceAdapter) - Constructor for class org.codehaus.activemq.store.cache.SimpleCachePersistenceAdapter
 
SimpleCharStream - class org.codehaus.activemq.selector.SimpleCharStream.
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.codehaus.activemq.selector.SimpleCharStream
 
SimpleCharStream(Reader, int, int) - Constructor for class org.codehaus.activemq.selector.SimpleCharStream
 
SimpleCharStream(Reader) - Constructor for class org.codehaus.activemq.selector.SimpleCharStream
 
SimpleCharStream(InputStream, int, int, int) - Constructor for class org.codehaus.activemq.selector.SimpleCharStream
 
SimpleCharStream(InputStream, int, int) - Constructor for class org.codehaus.activemq.selector.SimpleCharStream
 
SimpleCharStream(InputStream) - Constructor for class org.codehaus.activemq.selector.SimpleCharStream
 
SimpleConnectionManager - class org.codehaus.activemq.ra.SimpleConnectionManager.
A simple implementation of a ConnectionManager.
SimpleConnectionManager() - Constructor for class org.codehaus.activemq.ra.SimpleConnectionManager
 
SimpleDestinationFilter - class org.codehaus.activemq.filter.SimpleDestinationFilter.
Matches messages sent to an exact destination
SimpleDestinationFilter(Destination) - Constructor for class org.codehaus.activemq.filter.SimpleDestinationFilter
 
SimpleMessageCache - class org.codehaus.activemq.store.cache.SimpleMessageCache.
A simple cache that stores messages in memory.
SimpleMessageCache() - Constructor for class org.codehaus.activemq.store.cache.SimpleMessageCache
 
SimpleMessageCache(int) - Constructor for class org.codehaus.activemq.store.cache.SimpleMessageCache
 
SpooledBoundedPacketQueue - class org.codehaus.activemq.message.util.SpooledBoundedPacketQueue.
Implements a controlled thread safe queue, with Packets being spooled to disk for reading asynchronously.
SpooledBoundedPacketQueue(File, String, long, int) - Constructor for class org.codehaus.activemq.message.util.SpooledBoundedPacketQueue
Constructor for SpooledBoundedPacketQueue
SpooledBoundedPacketQueue(File, String) - Constructor for class org.codehaus.activemq.message.util.SpooledBoundedPacketQueue
Constructor for SpooledBoundedPacketQueue
SpringBrokerContainerFactory - class org.codehaus.activemq.spring.SpringBrokerContainerFactory.
A Spring implementatation of BrokerContainerFactory which uses an XML deployment configuration file to load and configure a BrokerContainer
SpringBrokerContainerFactory() - Constructor for class org.codehaus.activemq.spring.SpringBrokerContainerFactory
 
SpringBrokerContainerFactory(Resource) - Constructor for class org.codehaus.activemq.spring.SpringBrokerContainerFactory
 
SslTransportChannelFactory - class org.codehaus.activemq.transport.ssl.SslTransportChannelFactory.
An SSL implementation of a TransportChannelFactory
SslTransportChannelFactory() - Constructor for class org.codehaus.activemq.transport.ssl.SslTransportChannelFactory
 
SslTransportChannelFactory(SSLSocketFactory) - Constructor for class org.codehaus.activemq.transport.ssl.SslTransportChannelFactory
 
SslTransportServerChannelFactory - class org.codehaus.activemq.transport.ssl.SslTransportServerChannelFactory.
An SSL implementation of a TransportServerChannelFactory
SslTransportServerChannelFactory() - Constructor for class org.codehaus.activemq.transport.ssl.SslTransportServerChannelFactory
 
SslTransportServerChannelFactory(SSLServerSocketFactory) - Constructor for class org.codehaus.activemq.transport.ssl.SslTransportServerChannelFactory
 
StatementProvider - interface org.codehaus.activemq.store.jdbc.StatementProvider.
Generates the SQL statements that are used by the JDBCAdapter.
StatisticImpl - class org.codehaus.activemq.management.StatisticImpl.
Base class for a Statistic implementation
StatisticImpl(String, String, String) - Constructor for class org.codehaus.activemq.management.StatisticImpl
 
StatsCapable - interface org.codehaus.activemq.management.StatsCapable.
Represents an object which is capable of providing some stats
StatsImpl - class org.codehaus.activemq.management.StatsImpl.
Base class for a Stats implementation
StatsImpl() - Constructor for class org.codehaus.activemq.management.StatsImpl
 
StatsImpl(Map) - Constructor for class org.codehaus.activemq.management.StatsImpl
 
StreamJDBCAdapter - class org.codehaus.activemq.store.jdbc.adapter.StreamJDBCAdapter.
This JDBCAdapter inserts and extracts BLOB data using the setBinaryStream()/getBinaryStream() operations.
StreamJDBCAdapter() - Constructor for class org.codehaus.activemq.store.jdbc.adapter.StreamJDBCAdapter
 
StreamJDBCAdapter(StatementProvider) - Constructor for class org.codehaus.activemq.store.jdbc.adapter.StreamJDBCAdapter
 
StringDataBinding - class org.codehaus.activemq.store.bdbn.StringDataBinding.
A DataBinding for a simple String serialiation
StringDataBinding() - Constructor for class org.codehaus.activemq.store.bdbn.StringDataBinding
 
StringDataFormat - class org.codehaus.activemq.store.bdbn.StringDataFormat.
 
StringDataFormat() - Constructor for class org.codehaus.activemq.store.bdbn.StringDataFormat
 
StubSecondaryKeyGenerator - class org.codehaus.activemq.store.bdb.StubSecondaryKeyGenerator.
 
StubSecondaryKeyGenerator() - Constructor for class org.codehaus.activemq.store.bdb.StubSecondaryKeyGenerator
 
SubscriberEntry - class org.codehaus.activemq.service.SubscriberEntry.
Represents a durable subscribers subscription entry which contains details of the subscription and the subscriber's unique ID
SubscriberEntry() - Constructor for class org.codehaus.activemq.service.SubscriberEntry
 
Subscription - interface org.codehaus.activemq.service.Subscription.
A Subscription holds messages to be dispatched to a a Client Consumer
SubscriptionContainer - interface org.codehaus.activemq.service.SubscriptionContainer.
Represents a possibly persistent container of subscription objects
SubscriptionContainerImpl - class org.codehaus.activemq.service.impl.SubscriptionContainerImpl.
A default RAM only implementation of the SubscriptionContainer
SubscriptionContainerImpl(RedeliveryPolicy) - Constructor for class org.codehaus.activemq.service.impl.SubscriptionContainerImpl
 
SubscriptionContainerImpl(Map, RedeliveryPolicy) - Constructor for class org.codehaus.activemq.service.impl.SubscriptionContainerImpl
 
SubscriptionImpl - class org.codehaus.activemq.service.impl.SubscriptionImpl.
A Subscription holds messages to be dispatched to a a Client Consumer
SubscriptionImpl(Dispatcher, BrokerClient, ConsumerInfo, Filter, RedeliveryPolicy) - Constructor for class org.codehaus.activemq.service.impl.SubscriptionImpl
Create a Subscription object that holds messages to be dispatched to a Consumer
SwitchTo(int) - Method in class org.codehaus.activemq.selector.SelectorParserTokenManager
 
safeClose(Session) - Static method in class org.codehaus.activemq.ra.ActiveMQBaseEndpointWorker
 
safeClose(ConnectionConsumer) - Static method in class org.codehaus.activemq.ra.ActiveMQBaseEndpointWorker
 
seek(int) - Method in class org.codehaus.activemq.journal.impl.Segment
 
send(Message) - Method in class org.codehaus.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.codehaus.activemq.ActiveMQMessageProducer
Sends a message to the destination, specifying delivery mode, priority, and time to live.
send(Destination, Message) - Method in class org.codehaus.activemq.ActiveMQMessageProducer
Sends a message to a destination for an unidentified message producer.
send(Destination, Message, int, int, long) - Method in class org.codehaus.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.codehaus.activemq.ActiveMQQueueSender
Sends a message to a queue for an unidentified message producer.
send(Queue, Message, int, int, long) - Method in class org.codehaus.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.codehaus.activemq.ActiveMQSession
send the message for dispatch by the broker
send(Packet) - Method in class org.codehaus.activemq.broker.impl.BrokerClientImpl
 
send(Packet) - Method in interface org.codehaus.activemq.transport.TransportChannel
synchronously send a Packet
send(Packet, int) - Method in interface org.codehaus.activemq.transport.TransportChannel
Synchrnously send a Packet
send(Packet) - Method in class org.codehaus.activemq.transport.TransportChannelSupport
synchronously send a Packet
send(Packet, int) - Method in class org.codehaus.activemq.transport.TransportChannelSupport
Synchronously send a Packet
send(Packet) - Method in class org.codehaus.activemq.transport.composite.CompositeTransportChannel
 
send(Packet, int) - Method in class org.codehaus.activemq.transport.composite.CompositeTransportChannel
 
send(Packet, int) - Method in class org.codehaus.activemq.transport.reliable.ReliableTransportChannel
 
send(Destination, Message) - Method in class org.codehaus.activemq.web.WebClient
 
sendConnectionInfoToBroker() - Method in class org.codehaus.activemq.ActiveMQConnection
 
sendConnectionInfoToBroker(int, boolean) - Method in class org.codehaus.activemq.ActiveMQConnection
Send the ConnectionInfo to the Broker
sendMatchingInitialImages(BrokerClient, ConsumerInfo, DestinationFilter) - Method in class org.codehaus.activemq.service.impl.InitialImageMessageContainerManager
 
sendMessage(BrokerClient, ActiveMQMessage) - Method in interface org.codehaus.activemq.broker.Broker
send a message to the broker
sendMessage(BrokerClient, ActiveMQMessage) - Method in interface org.codehaus.activemq.broker.BrokerConnector
Send a non-transacted message to the Broker
sendMessage(BrokerClient, ActiveMQMessage) - Method in interface org.codehaus.activemq.broker.BrokerContainer
Send a non-transacted message to the Broker
sendMessage(BrokerClient, ActiveMQMessage) - Method in class org.codehaus.activemq.broker.impl.BrokerConnectorImpl
Send a non-transacted message to the Broker
sendMessage(BrokerClient, ActiveMQMessage) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
Send a non-transacted message to the Broker
sendMessage(BrokerClient, ActiveMQMessage) - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
send a message to the broker
sendMessage(BrokerClient, ActiveMQMessage) - Method in interface org.codehaus.activemq.service.MessageContainerManager
 
sendMessage(BrokerClient, ActiveMQMessage) - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageManager
 
sendMessage(BrokerClient, ActiveMQMessage) - Method in class org.codehaus.activemq.service.boundedvm.TransientTopicBoundedMessageManager
 
sendMessage(BrokerClient, ActiveMQMessage) - Method in class org.codehaus.activemq.service.impl.DurableQueueMessageContainerManager
 
sendMessage(BrokerClient, ActiveMQMessage) - Method in class org.codehaus.activemq.service.impl.DurableTopicMessageContainerManager
 
sendMessage(BrokerClient, ActiveMQMessage) - Method in class org.codehaus.activemq.service.impl.InitialImageMessageContainerManager
 
sendMessage(BrokerClient, ActiveMQMessage) - Method in class org.codehaus.activemq.service.impl.ProxyMessageContainerManager
 
sendMessage(BrokerClient, ActiveMQMessage) - Method in class org.codehaus.activemq.service.impl.TransientTopicMessageContainerManager
 
sendMessageRateTime - Variable in class org.codehaus.activemq.management.JMSQueueStatsImpl
 
sendMessageResponse(HttpServletRequest, HttpServletResponse, Message) - Method in class org.codehaus.activemq.web.MessageServlet
 
sendTransactedMessage(BrokerClient, String, ActiveMQMessage) - Method in interface org.codehaus.activemq.broker.Broker
send a message to the broker within a transaction
sendTransactedMessage(BrokerClient, String, ActiveMQMessage) - Method in interface org.codehaus.activemq.broker.BrokerConnector
send message with a transaction context
sendTransactedMessage(BrokerClient, String, ActiveMQMessage) - Method in interface org.codehaus.activemq.broker.BrokerContainer
send message with a transaction context
sendTransactedMessage(BrokerClient, String, ActiveMQMessage) - Method in class org.codehaus.activemq.broker.impl.BrokerConnectorImpl
send message with a transaction context
sendTransactedMessage(BrokerClient, String, ActiveMQMessage) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
send message with a transaction context
sendTransactedMessage(BrokerClient, String, ActiveMQMessage) - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
send a message to the broker within a transaction
sequenceDataType - Variable in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
sequenceGenerator - Variable in class org.codehaus.activemq.journal.impl.JournalImpl
 
sequenceGenerator - Variable in class org.codehaus.activemq.store.jdbc.JDBCMessageStore
 
sequenceGenerator - Variable in class org.codehaus.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
sequenceId - Variable in class org.codehaus.activemq.journal.impl.Mark
 
sequenceId - Variable in class org.codehaus.activemq.journal.impl.RecordFooter
 
sequenceId - Variable in class org.codehaus.activemq.journal.impl.RecordHeader
 
serialVersionUID - Static variable in class org.codehaus.activemq.util.DefaultComparator
 
serialize(Object) - Static method in class org.codehaus.activemq.util.SerializationHelper
 
serverUrl - Variable in class org.codehaus.activemq.ra.ActiveMQConnectionRequestInfo
 
session - Variable in class org.codehaus.activemq.ActiveMQMessageConsumer
 
session - Variable in class org.codehaus.activemq.ActiveMQMessageProducer
 
session - Variable in class org.codehaus.activemq.ra.ActiveMQAsfEndpointWorker.ServerSessionImpl
 
session - Variable in class org.codehaus.activemq.web.WebClient.SessionConsumerPair
 
sessionCreated(HttpSessionEvent) - Method in class org.codehaus.activemq.web.ConnectionManager
 
sessionDestroyed(HttpSessionEvent) - Method in class org.codehaus.activemq.web.ConnectionManager
 
sessionDidActivate(HttpSessionEvent) - Method in class org.codehaus.activemq.web.WebClient
 
sessionIds - Variable in class org.codehaus.activemq.ra.ActiveMQAsfEndpointWorker.ServerSessionPoolImpl
 
sessionWillPassivate(HttpSessionEvent) - Method in class org.codehaus.activemq.web.WebClient
 
set(int, Object) - Method in interface org.codehaus.activemq.service.QueueList
Replaces the element at the specified position in this list with the specified element.
set(int, Object) - Method in class org.codehaus.activemq.service.impl.DefaultQueueList
 
set(int, Object) - Method in class org.codehaus.activemq.service.impl.QueueListSupport
 
set(int, boolean) - Method in class org.codehaus.activemq.util.BitArray
set the boolean value at the index
setActive(boolean) - Method in interface org.codehaus.activemq.service.Subscription
set the state of the Subscription
setActive(boolean) - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
 
setActiveConsumer(BrokerClient, ConsumerInfo) - Method in interface org.codehaus.activemq.service.Subscription
Set the active consumer info
setActiveConsumer(BrokerClient, ConsumerInfo) - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
Set the active consumer info
setAsyncSend(boolean) - Method in class org.codehaus.activemq.transport.vm.VmTransportChannel
 
setBackOffIncreaseRate(double) - Method in class org.codehaus.activemq.service.RedeliveryPolicy
 
setBackOffMode(boolean) - Method in class org.codehaus.activemq.service.RedeliveryPolicy
 
setBacklog(int) - Method in class org.codehaus.activemq.transport.tcp.TcpTransportServerChannel
 
setBinaryData(PreparedStatement, int, byte[]) - Method in class org.codehaus.activemq.store.jdbc.adapter.BytesJDBCAdapter
 
setBinaryData(PreparedStatement, int, byte[]) - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
setBinaryData(PreparedStatement, int, byte[]) - Method in class org.codehaus.activemq.store.jdbc.adapter.StreamJDBCAdapter
 
setBinaryDataType(String) - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
setBit(long, boolean) - Method in class org.codehaus.activemq.util.BitArrayBin
Set a bit
setBitArray(BitArray) - Method in class org.codehaus.activemq.message.AbstractPacket
 
setBodyAsBytes(byte[]) - Method in class org.codehaus.activemq.message.ActiveMQBytesMessage
 
setBodyAsBytes(byte[]) - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
setBodyAsBytes(byte[]) - Method in class org.codehaus.activemq.message.ActiveMQStreamMessage
 
setBoolean(String, boolean) - Method in class org.codehaus.activemq.message.ActiveMQMapMessage
Sets a boolean value with the specified name into the Map.
setBooleanProperty(String, boolean) - Method in class org.codehaus.activemq.message.ActiveMQMessage
Sets a boolean property value with the specified name into the message.
setBroker(Broker) - Method in interface org.codehaus.activemq.service.Transaction
Called when this transaction has been recovered from disk to re-associate it with the broker in which its being applied.
setBroker(Broker) - Method in class org.codehaus.activemq.service.impl.AbstractTransaction
Called after deserialization to register the broker
setBrokerContainer(BrokerContainer) - Method in class org.codehaus.activemq.transport.NetworkChannel
 
setBrokerContainerFactory(BrokerContainerFactory) - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
 
setBrokerContext(BrokerContext) - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
 
setBrokerMessageCapacity(int) - Method in class org.codehaus.activemq.message.Receipt
 
setBrokerName(String) - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
 
setBrokerName(String) - Method in class org.codehaus.activemq.message.BrokerInfo
 
setBrokerName(String) - Method in class org.codehaus.activemq.message.Receipt
 
setBrokerName(String) - Method in class org.codehaus.activemq.spring.ActiveMQBeanDefinitionReader
 
setBrokerURL(String) - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
 
setBrokerXmlConfig(String) - Method in class org.codehaus.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.codehaus.activemq.ActiveMQMessageConsumer
Set true if only a Browser
setBrowser(boolean) - Method in class org.codehaus.activemq.message.ConsumerInfo
 
setBufferClassName(String) - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
setBufferSize(int) - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
setByte(String, byte) - Method in class org.codehaus.activemq.message.ActiveMQMapMessage
Sets a byte value with the specified name into the Map.
setByteProperty(String, byte) - Method in class org.codehaus.activemq.message.ActiveMQMessage
Sets a byte property value with the specified name into the message.
setBytes(String, byte[]) - Method in class org.codehaus.activemq.message.ActiveMQMapMessage
Sets a byte array value with the specified name into the Map.
setBytes(String, byte[], int, int) - Method in class org.codehaus.activemq.message.ActiveMQMapMessage
Sets a portion of the byte array value with the specified name into the Map.
setCacheMessageStore(CacheMessageStore) - Method in class org.codehaus.activemq.store.cache.CacheMessageStore
 
setCacheMessageStore(CacheMessageStore) - Method in interface org.codehaus.activemq.store.cache.CacheMessageStoreAware
 
setCacheMessageStore(CacheMessageStore) - Method in class org.codehaus.activemq.store.journal.JournalMessageStore
 
setCacheSize(int) - Method in class org.codehaus.activemq.store.cache.SimpleCachePersistenceAdapter
 
setCapacity(int) - Method in class org.codehaus.activemq.capacity.CapacityMonitorEvent
 
setCapacity(int) - Method in class org.codehaus.activemq.message.CapacityInfo
 
setChangeTimeout(boolean) - Method in class org.codehaus.activemq.transport.tcp.TcpTransportChannel
 
setChannelConfiguration(Object) - Method in class org.codehaus.activemq.transport.jgroups.JGroupsTransportChannelFactory
 
setChannelFactory(ChannelFactory) - Method in class org.codehaus.activemq.transport.jgroups.JGroupsTransportChannelFactory
 
setChannelName(String) - Method in class org.codehaus.activemq.transport.jgroups.JGroupsTransportChannelFactory
 
setChannelStatus(int) - Method in class org.codehaus.activemq.transport.TransportStatusEvent
 
setChar(String, char) - Method in class org.codehaus.activemq.message.ActiveMQMapMessage
Sets a Unicode character value with the specified name into the Map.
setChecksumEnabled(boolean) - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
setClientID(String) - Method in class org.codehaus.activemq.ActiveMQConnection
Sets the client identifier for this connection.
setClientID(String) - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
 
setClientID(String) - Method in class org.codehaus.activemq.ra.JMSConnectionProxy
 
setClientID(String) - Method in class org.codehaus.activemq.service.SubscriberEntry
 
setClientID(String) - Method in interface org.codehaus.activemq.transport.TransportChannel
Provides a way to specify the client ID that this channel is using
setClientID(String) - Method in class org.codehaus.activemq.transport.TransportChannelSupport
 
setClientID(String) - Method in class org.codehaus.activemq.transport.http.HttpTransportChannelSupport
 
setClientId(String) - Method in class org.codehaus.activemq.message.ConnectionInfo
 
setClientId(String) - Method in class org.codehaus.activemq.message.ConsumerInfo
 
setClientId(String) - Method in class org.codehaus.activemq.message.DurableUnsubscribe
 
setClientId(String) - Method in class org.codehaus.activemq.message.ProducerInfo
 
setClientId(String) - Method in class org.codehaus.activemq.message.SessionInfo
 
setClientId(String) - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
 
setClientVersion(String) - Method in class org.codehaus.activemq.message.ConnectionInfo
 
setClientid(String) - Method in class org.codehaus.activemq.ra.ActiveMQConnectionRequestInfo
 
setClientid(String) - Method in class org.codehaus.activemq.ra.ActiveMQResourceAdapter
 
setClockDaemon(ClockDaemon) - Method in class org.codehaus.activemq.store.journal.JournalPersistenceAdapter
 
setClosed(boolean) - Method in class org.codehaus.activemq.message.ConnectionInfo
 
setClusterName(String) - Method in class org.codehaus.activemq.message.BrokerInfo
 
setClusterName(String) - Method in class org.codehaus.activemq.message.Receipt
 
setConfig(DatabaseConfig) - Method in class org.codehaus.activemq.store.bdb.BDbPersistenceAdapter
 
setConfiguration(Configuration) - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
setConnection(Connection) - Method in class org.codehaus.activemq.util.JmsLogAppenderSupport
 
setConnectionMemoryLimit(int) - Method in class org.codehaus.activemq.ActiveMQConnection
Set the maximum amount of memory this Connection should use for buffered inbound messages
setConsumerId(String) - Method in class org.codehaus.activemq.ActiveMQMessageConsumer
 
setConsumerId(String) - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
setConsumerId(String) - Method in class org.codehaus.activemq.message.ConsumerInfo
 
setConsumerId(String) - Method in class org.codehaus.activemq.message.MessageAck
 
setConsumerInfo(ConsumerInfo) - Method in class org.codehaus.activemq.service.boundedvm.TransientSubscription
 
setConsumerName(String) - Method in class org.codehaus.activemq.ActiveMQMessageConsumer
Set the name of the Consumer - used for durable subscribers
setConsumerName(String) - Method in class org.codehaus.activemq.message.ConsumerInfo
 
setConsumerName(String) - Method in class org.codehaus.activemq.service.SubscriberEntry
 
setConsumerNo(int) - Method in class org.codehaus.activemq.message.ConsumerInfo
 
setConsumerNos(int[]) - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
setConsumerNumber(int) - Method in class org.codehaus.activemq.ActiveMQMessageConsumer
Set the locally unique consumer number
setContainer(MessageContainer) - Method in class org.codehaus.activemq.service.impl.MessagePointer
 
setContainerManagerMap(Map) - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
setContainerNameDataType(String) - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
setContexTransaction(Transaction) - Method in interface org.codehaus.activemq.service.TransactionManager
 
setContexTransaction(Transaction) - Method in class org.codehaus.activemq.service.impl.TransactionManagerImpl
 
setCorrelationId(String) - Method in class org.codehaus.activemq.message.CapacityInfo
 
setCorrelationId(String) - Method in class org.codehaus.activemq.message.Receipt
 
setCount(long) - Method in class org.codehaus.activemq.management.CountStatisticImpl
 
setCurrent(long) - Method in class org.codehaus.activemq.management.RangeStatisticImpl
 
setCurrentValue(long) - Method in class org.codehaus.activemq.capacity.BasicCapacityMonitor
set the current value of the capacity
setCurrentValue(long) - Method in interface org.codehaus.activemq.capacity.CapacityMonitor
set the current value of the capacity
setCurrentValue(long) - Method in class org.codehaus.activemq.capacity.DelegateCapacityMonitor
set the current value of the capacity
setDataSource(DataSource) - Method in class org.codehaus.activemq.store.jdbc.JDBCPersistenceAdapter
 
setDebugStream(PrintStream) - Method in class org.codehaus.activemq.selector.SelectorParserTokenManager
 
setDelegate(CapacityMonitor) - Method in class org.codehaus.activemq.capacity.DelegateCapacityMonitor
Set the delegated one
setDelegate(MessageContainerManager) - Method in class org.codehaus.activemq.service.impl.ProxyMessageContainerManager
 
setDeleteKey(DatabaseEntry) - Method in class org.codehaus.activemq.store.bdb.SequenceNumberCreator
Sets the next primary key to return, such as doing a delete
setDeliveryMode(int) - Method in class org.codehaus.activemq.ActiveMQMessageProducer
Sets the producer's default delivery mode.
setDestination(ActiveMQDestination) - Method in class org.codehaus.activemq.message.ConsumerInfo
 
setDestination(ActiveMQDestination) - Method in class org.codehaus.activemq.message.MessageAck
 
setDestination(ActiveMQDestination) - Method in class org.codehaus.activemq.message.ProducerInfo
 
setDestination(String) - Method in class org.codehaus.activemq.service.SubscriberEntry
 
setDestination(ActiveMQDestination) - Method in class org.codehaus.activemq.transport.NetworkMessageBridge
 
setDestinationName(String) - Method in class org.codehaus.activemq.ra.ActiveMQActivationSpec
 
setDestinationType(String) - Method in class org.codehaus.activemq.ra.ActiveMQActivationSpec
 
setDirectory(File) - Method in class org.codehaus.activemq.store.bdb.BDbPersistenceAdapter
 
setDirectory(File) - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
setDirectory(File) - Method in class org.codehaus.activemq.store.jdbm.JdbmPersistenceAdapter
 
setDirectory(File) - Method in class org.codehaus.activemq.store.journal.JournalPersistenceAdapter
 
setDisableMessageID(boolean) - Method in class org.codehaus.activemq.ActiveMQMessageProducer
Sets whether message IDs are disabled.
setDisableMessageTimestamp(boolean) - Method in class org.codehaus.activemq.ActiveMQMessageProducer
Sets whether message timestamps are disabled.
setDiscoveryAgent(DiscoveryAgent) - Method in interface org.codehaus.activemq.broker.BrokerContainer
 
setDiscoveryAgent(DiscoveryAgent) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
 
setDiscoveryAgent(DiscoveryAgent) - Method in class org.codehaus.activemq.transport.DiscoveryTransportChannel
 
setDiscoveryAgent(DiscoveryAgent) - Method in class org.codehaus.activemq.transport.DiscoveryTransportChannelFactorySupport
 
setDiscoveryListener(DiscoveryListener) - Method in interface org.codehaus.activemq.transport.DiscoveryAgent
 
setDiscoveryListener(DiscoveryListener) - Method in class org.codehaus.activemq.transport.DiscoveryAgentSupport
 
setDispatched(boolean) - Method in class org.codehaus.activemq.service.impl.MessagePointer
 
setDoDispatch(boolean) - Method in class org.codehaus.activemq.ActiveMQSessionExecutor
 
setDouble(String, double) - Method in class org.codehaus.activemq.message.ActiveMQMapMessage
Sets a double value with the specified name into the Map.
setDoubleProperty(String, double) - Method in class org.codehaus.activemq.message.ActiveMQMessage
Sets a double property value with the specified name into the message.
setDurableSubAcksTableName(String) - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
setDurableSubscriptionName(String) - Method in class org.codehaus.activemq.ra.ActiveMQActivationSpec
 
setDurableTopic(boolean) - Method in class org.codehaus.activemq.transport.NetworkMessageBridge
sett the durable value of the consumer
setDurableTopicPrefetch(int) - Method in class org.codehaus.activemq.ActiveMQPrefetchPolicy
 
setEndpointWorkerType(String) - Method in class org.codehaus.activemq.ra.ActiveMQResourceAdapter
 
setEntryBrokerName(String) - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
setEntryClusterName(String) - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
setEnvironment(Environment) - Method in class org.codehaus.activemq.store.bdb.BDbPersistenceAdapter
 
setEstablishConnectionTimeout(long) - Method in class org.codehaus.activemq.transport.composite.CompositeTransportChannel
 
setException(Throwable) - Method in class org.codehaus.activemq.message.Receipt
 
setExceptionListener(ExceptionListener) - Method in class org.codehaus.activemq.ActiveMQConnection
Sets an exception listener for this connection.
setExceptionListener(ExceptionListener) - Method in class org.codehaus.activemq.ra.JMSConnectionProxy
 
setExceptionListener(ExceptionListener) - Method in interface org.codehaus.activemq.transport.TransportChannel
Set an exception listener to listen for asynchronously generated exceptions
setExceptionListener(ExceptionListener) - Method in class org.codehaus.activemq.transport.TransportChannelSupport
Set an exception listener to listen for asynchronously generated exceptions
setExceptionListener(ExceptionListener) - Method in class org.codehaus.activemq.transport.composite.CompositeTransportChannel
 
setExceptionListener(ExceptionListener) - Method in class org.codehaus.activemq.util.MessageListenerSupport
 
setFailed(boolean) - Method in class org.codehaus.activemq.message.Receipt
 
setFailureSleepTime(long) - Method in class org.codehaus.activemq.transport.composite.CompositeTransportChannel
 
setFilter(Filter) - Method in class org.codehaus.activemq.service.boundedvm.TransientSubscription
 
setFilter(Filter) - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
 
setFloat(String, float) - Method in class org.codehaus.activemq.message.ActiveMQMapMessage
Sets a float value with the specified name into the Map.
setFloatProperty(String, float) - Method in class org.codehaus.activemq.message.ActiveMQMessage
Sets a float property value with the specified name into the message.
setFlowControlTimeout(long) - Method in class org.codehaus.activemq.message.CapacityInfo
 
setFlushSleepTime(int) - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
setHostName(String) - Method in class org.codehaus.activemq.message.ConnectionInfo
 
setId(String) - Method in class org.codehaus.activemq.message.AbstractPacket
Set the unique id for this Packet
setId(String) - Method in interface org.codehaus.activemq.message.Packet
Set the unique id for this Packet
setIndentLevel(int) - Method in class org.codehaus.activemq.util.IndentPrinter
 
setInitialContextFactoryName(String) - Method in class org.codehaus.activemq.util.JndiJmsLogAppender
 
setInitialRedeliveryTimeout(long) - Method in class org.codehaus.activemq.service.RedeliveryPolicy
 
setInt(String, int) - Method in class org.codehaus.activemq.message.ActiveMQMapMessage
Sets an int value with the specified name into the Map.
setIntProperty(String, int) - Method in class org.codehaus.activemq.message.ActiveMQMessage
Sets an int property value with the specified name into the message.
setJMSClientID(String) - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
setJMSCorrelationID(String) - Method in class org.codehaus.activemq.message.ActiveMQMessage
Sets the correlation ID for the message.
setJMSCorrelationIDAsBytes(byte[]) - Method in class org.codehaus.activemq.message.ActiveMQMessage
Sets the correlation ID as an array of bytes for the message.
setJMSDeliveryMode(int) - Method in class org.codehaus.activemq.message.ActiveMQMessage
Sets the DeliveryMode value for this message.
setJMSDestination(Destination) - Method in class org.codehaus.activemq.message.ActiveMQMessage
Sets the Destination object for this message.
setJMSExpiration(long) - Method in class org.codehaus.activemq.message.ActiveMQMessage
Sets the message's expiration value.
setJMSMessageID(String) - Method in class org.codehaus.activemq.message.ActiveMQMessage
Sets the message ID.
setJMSMessageIdentity(MessageIdentity) - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
setJMSPriority(int) - Method in class org.codehaus.activemq.message.ActiveMQMessage
Sets the priority level for this message.
setJMSRedelivered(boolean) - Method in class org.codehaus.activemq.message.ActiveMQMessage
Specifies whether this message is being redelivered.
setJMSReplyTo(Destination) - Method in class org.codehaus.activemq.message.ActiveMQMessage
Sets the Destination object to which a reply to this message should be sent.
setJMSTimestamp(long) - Method in class org.codehaus.activemq.message.ActiveMQMessage
Sets the message timestamp.
setJMSType(String) - Method in class org.codehaus.activemq.message.ActiveMQMessage
Sets the message type.
setJmdns(JmDNS) - Method in class org.codehaus.activemq.transport.zeroconf.ZeroconfDiscoveryAgent
 
setJndiName(String) - Method in class org.codehaus.activemq.util.JndiJmsLogAppender
 
setJournalEventListener(JournalEventListener) - Method in interface org.codehaus.activemq.journal.Journal
Registers a JournalEventListener that will receive notifications from the Journal.
setJournalEventListener(JournalEventListener) - Method in class org.codehaus.activemq.journal.JournalStatsFilter
 
setJournalEventListener(JournalEventListener) - Method in class org.codehaus.activemq.journal.howl.HowlJournal
 
setJournalEventListener(JournalEventListener) - Method in class org.codehaus.activemq.journal.impl.JournalImpl
 
setJournalEventListener(JournalEventListener) - Method in class org.codehaus.activemq.journal.impl.LogFileManager
 
setLastAcknowledgedMessageID(Subscription, MessageIdentity) - Method in interface org.codehaus.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.
setLastAcknowledgedMessageID(Subscription, MessageIdentity) - Method in class org.codehaus.activemq.service.impl.DurableTopicMessageContainer
 
setLastAcknowledgedMessageIdentity(Subscription, MessageIdentity) - Method in interface org.codehaus.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(Subscription, MessageIdentity) - Method in class org.codehaus.activemq.store.bdb.BDbTopicMessageStore
 
setLastAcknowledgedMessageIdentity(Subscription, MessageIdentity) - Method in class org.codehaus.activemq.store.bdbn.BDbTopicMessageStore
 
setLastAcknowledgedMessageIdentity(Subscription, MessageIdentity) - Method in class org.codehaus.activemq.store.cache.CacheTopicMessageStore
 
setLastAcknowledgedMessageIdentity(Subscription, MessageIdentity) - Method in class org.codehaus.activemq.store.jdbc.JDBCTopicMessageStore
 
setLastAcknowledgedMessageIdentity(Subscription, MessageIdentity) - Method in class org.codehaus.activemq.store.jdbm.JdbmTopicMessageStore
 
setLastAcknowledgedMessageIdentity(Subscription, MessageIdentity) - Method in class org.codehaus.activemq.store.vm.VMTopicMessageStore
 
setLastMessageIdentifier(MessageIdentity) - Method in interface org.codehaus.activemq.service.Subscription
Used for a Queue based Subscription to set the last acknowledged message ID
setLastMessageIdentifier(MessageIdentity) - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
 
setLastSequenceId(long) - Method in class org.codehaus.activemq.util.LongSequenceGenerator
 
setLeft(Expression) - Method in class org.codehaus.activemq.filter.BinaryExpression
 
setLocalAddress(InetAddress) - Method in class org.codehaus.activemq.transport.zeroconf.ZeroconfDiscoveryAgent
 
setLocalBrokerName(String) - Method in class org.codehaus.activemq.transport.NetworkMessageBridge
 
setLocalDetails(Map) - Method in class org.codehaus.activemq.transport.DiscoveryNetworkConnector
 
setLocalSession(Session) - Method in class org.codehaus.activemq.transport.NetworkMessageBridge
 
setLocalTransactionEventListener(LocalTransactionEventListener) - Method in class org.codehaus.activemq.ActiveMQSession
Used by the resource adapter to listen to transaction events.
setLocalhost(String) - Method in class org.codehaus.activemq.transport.zeroconf.ZeroconfDiscoveryAgent
 
setLogFileDir(String) - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
setLogFileExt(String) - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
setLogFileName(String) - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
setLogWriter(PrintWriter) - Method in class org.codehaus.activemq.ra.ActiveMQManagedConnection
 
setLogWriter(PrintWriter) - Method in class org.codehaus.activemq.ra.ActiveMQManagedConnectionFactory
 
setLong(String, long) - Method in class org.codehaus.activemq.message.ActiveMQMapMessage
Sets a long value with the specified name into the Map.
setLongProperty(String, long) - Method in class org.codehaus.activemq.message.ActiveMQMessage
Sets a long property value with the specified name into the message.
setLongTermPersistence(PersistenceAdapter) - Method in class org.codehaus.activemq.store.cache.CachePersistenceAdapter
 
setLongTermPersistence(PersistenceAdapter) - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
setLongTermPersistence(PersistenceAdapter) - Method in class org.codehaus.activemq.store.journal.JournalPersistenceAdapter
 
setMaintainDestinationStats(boolean) - Method in class org.codehaus.activemq.service.impl.MessageContainerManagerSupport
 
setManager(RecordManager) - Method in class org.codehaus.activemq.store.jdbm.JdbmPersistenceAdapter
 
setMark(RecordLocation, boolean) - Method in interface org.codehaus.activemq.journal.Journal
Informs the journal that all the journal space up to the location is no longer needed and can be reclaimed for reuse.
setMark(RecordLocation, boolean) - Method in class org.codehaus.activemq.journal.JournalStatsFilter
 
setMark(RecordLocation, boolean) - Method in class org.codehaus.activemq.journal.howl.HowlJournal
 
setMark(RecordLocation, boolean) - Method in class org.codehaus.activemq.journal.impl.JournalImpl
 
setMark(RecordLocationImpl, boolean) - Method in class org.codehaus.activemq.journal.impl.LogFileManager
 
setMaxBlocksPerFile(int) - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
setMaxBuffers(int) - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
setMaxLogFiles(int) - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
setMaxOutstandingMessages(int) - Method in class org.codehaus.activemq.transport.tcp.TcpTransportServerChannel
 
setMaximumCacheSize(int) - Method in class org.codehaus.activemq.store.howl.HowlMessageStore
 
setMaximumCachedMessagesPerStore(int) - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
setMaximumMemoryUsage(long) - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
setMaximumRetries(int) - Method in class org.codehaus.activemq.transport.NetworkChannel
 
setMaximumRetries(int) - Method in class org.codehaus.activemq.transport.composite.CompositeTransportChannel
 
setMaximumRetryCount(int) - Method in class org.codehaus.activemq.service.RedeliveryPolicy
 
setMaximumTotalCachedMessages(int) - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
setMemoryUsage(int) - Method in class org.codehaus.activemq.message.AbstractPacket
Set a hint about how mujch memory this packet is consuming
setMemoryUsage(int) - Method in interface org.codehaus.activemq.message.Packet
Set a hint about how mujch memory this packet is consuming
setMessageAcknowledge(MessageAcknowledge) - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
setMessageConsumed(boolean) - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
setMessageContainer(MessageContainer) - Method in interface org.codehaus.activemq.store.TopicMessageStore
Called before the service is started so that the store can communicate with the container when recovering
setMessageContainer(MessageContainer) - Method in class org.codehaus.activemq.store.bdb.BDbMessageStore
 
setMessageContainer(MessageContainer) - Method in class org.codehaus.activemq.store.bdbn.BDbMessageStore
 
setMessageContainer(MessageContainer) - Method in class org.codehaus.activemq.store.cache.CacheTopicMessageStore
 
setMessageContainer(MessageContainer) - Method in class org.codehaus.activemq.store.jdbc.JDBCTopicMessageStore
 
setMessageContainer(MessageContainer) - Method in class org.codehaus.activemq.store.jdbm.JdbmMessageStore
 
setMessageContainer(MessageContainer) - Method in class org.codehaus.activemq.store.vm.VMTopicMessageStore
 
setMessageID(String) - Method in class org.codehaus.activemq.message.MessageAck
 
setMessageID(String) - Method in class org.codehaus.activemq.service.MessageIdentity
 
setMessageIdentity(MessageIdentity) - Method in class org.codehaus.activemq.service.impl.MessagePointer
 
setMessageListener(MessageListener) - Method in class org.codehaus.activemq.ActiveMQMessageConsumer
Sets the message consumer's MessageListener.
setMessageListener(MessageListener) - Method in class org.codehaus.activemq.ActiveMQSession
Sets the session's distinguished message listener (optional).
setMessageListener(MessageListener) - Method in class org.codehaus.activemq.ra.JMSSessionProxy
 
setMessageRead(boolean) - Method in class org.codehaus.activemq.message.MessageAck
 
setMessageSelector(String) - Method in class org.codehaus.activemq.ra.ActiveMQActivationSpec
 
setMessageTableName(String) - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
setMinBuffers(int) - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
setMonitorName(String) - Method in class org.codehaus.activemq.capacity.CapacityMonitorEvent
 
setMsgIdDataType(String) - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
setName(String) - Method in class org.codehaus.activemq.capacity.BasicCapacityMonitor
 
setName(String) - Method in interface org.codehaus.activemq.capacity.CapacityMonitor
Set the name of the CapacityMonitor
setName(String) - Method in class org.codehaus.activemq.capacity.DelegateCapacityMonitor
 
setNetworkChannels(List) - Method in class org.codehaus.activemq.transport.NetworkConnector
Sets a list of NetworkChannel instances
setNetworkConnectors(List) - Method in interface org.codehaus.activemq.broker.BrokerContainer
 
setNetworkConnectors(List) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
 
setNoLocal(boolean) - Method in class org.codehaus.activemq.message.ConsumerInfo
 
setNoLocal(boolean) - Method in class org.codehaus.activemq.ra.ActiveMQActivationSpec
 
setNoLocal(boolean) - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
 
setObject(String, Object) - Method in class org.codehaus.activemq.message.ActiveMQMapMessage
Sets an object value with the specified name into the Map.
setObject(Serializable) - Method in class org.codehaus.activemq.message.ActiveMQObjectMessage
Sets the serializable object containing this message's data.
setObjectPayload(Object) - Method in class org.codehaus.activemq.message.ActiveMQObjectMessage
 
setObjectProperty(String, Object) - Method in class org.codehaus.activemq.message.ActiveMQMessage
Sets a Java object property value with the specified name into the message.
setPacketListener(PacketListener) - Method in interface org.codehaus.activemq.transport.TransportChannel
Set a listener for Packets
setPacketListener(PacketListener) - Method in class org.codehaus.activemq.transport.TransportChannelSupport
Set a listener for Packets
setPacketListener(PacketListener) - Method in class org.codehaus.activemq.transport.composite.CompositeTransportChannel
 
setPacketListener(PacketListener) - Method in class org.codehaus.activemq.transport.vm.VmTransportChannel
 
setParent(CountStatisticImpl) - Method in class org.codehaus.activemq.management.CountStatisticImpl
 
setParent(CountStatistic, CountStatistic) - Method in class org.codehaus.activemq.management.JMSEndpointStatsImpl
 
setParent(TimeStatistic, TimeStatistic) - Method in class org.codehaus.activemq.management.JMSEndpointStatsImpl
 
setParent(TimeStatisticImpl) - Method in class org.codehaus.activemq.management.TimeStatisticImpl
 
setPassword(String) - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
 
setPassword(String) - Method in class org.codehaus.activemq.message.ConnectionInfo
 
setPassword(String) - Method in class org.codehaus.activemq.ra.ActiveMQConnectionRequestInfo
 
setPassword(String) - Method in class org.codehaus.activemq.ra.ActiveMQResourceAdapter
 
setPassword(String) - Method in class org.codehaus.activemq.util.JmsLogAppender
 
setPassword(String) - Method in class org.codehaus.activemq.util.JndiJmsLogAppender
 
setPendingMessageCountOnStartup(long) - Method in interface org.codehaus.activemq.management.JMSDestinationStats
On startup sets the pending message count
setPendingMessageCountOnStartup(long) - Method in class org.codehaus.activemq.management.JMSQueueStatsImpl
 
setPendingMessageCountOnStartup(long) - Method in class org.codehaus.activemq.management.JMSTopicStatsImpl
 
setPendingStop(boolean) - Method in interface org.codehaus.activemq.transport.TransportChannel
Give the TransportChannel a hint it's about to stop
setPendingStop(boolean) - Method in class org.codehaus.activemq.transport.TransportChannelSupport
Give the TransportChannel a hint it's about to stop
setPersistenceAdapter(PersistenceAdapter) - Method in interface org.codehaus.activemq.broker.Broker
set the persistence adaptor
setPersistenceAdapter(PersistenceAdapter) - Method in interface org.codehaus.activemq.broker.BrokerContainer
 
setPersistenceAdapter(PersistenceAdapter) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerFactoryImpl
 
setPersistenceAdapter(PersistenceAdapter) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
 
setPersistenceAdapter(PersistenceAdapter) - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
setPersistent(boolean) - Method in class org.codehaus.activemq.message.MessageAck
 
setPhysicalName(String) - Method in class org.codehaus.activemq.message.ActiveMQDestination
 
setPrefetchNumber(int) - Method in class org.codehaus.activemq.ActiveMQMessageConsumer
 
setPrefetchNumber(int) - Method in class org.codehaus.activemq.message.ConsumerInfo
 
setPrefetchPolicy(ActiveMQPrefetchPolicy) - Method in class org.codehaus.activemq.ActiveMQConnection
 
setPreparedTransactionStore(PreparedTransactionStore) - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
setPriority(int) - Method in class org.codehaus.activemq.ActiveMQMessageProducer
Sets the producer's default priority.
setPriority(int) - Method in class org.codehaus.activemq.transport.zeroconf.ZeroconfDiscoveryAgent
 
setProducer(MessageProducer) - Method in class org.codehaus.activemq.util.JmsLogAppenderSupport
 
setProducerID(String) - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
setProducerId(String) - Method in class org.codehaus.activemq.ActiveMQMessageProducer
 
setProducerId(String) - Method in class org.codehaus.activemq.message.ProducerInfo
 
setProperties(Properties) - Method in class org.codehaus.activemq.jndi.JNDIBaseStorable
set the properties for this instance as retrieved from JNDI
setProperties(Properties) - Method in interface org.codehaus.activemq.jndi.JNDIStorableInterface
set the properties for this instance as retrieved from JNDI
setProperties(Hashtable) - Method in class org.codehaus.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.codehaus.activemq.message.BrokerInfo
 
setProperties(Properties) - Method in class org.codehaus.activemq.message.ConnectionInfo
 
setProviderURL(String) - Method in class org.codehaus.activemq.util.JndiJmsLogAppender
 
setQueueBrowserPrefetch(int) - Method in class org.codehaus.activemq.ActiveMQPrefetchPolicy
 
setQueuePrefetch(int) - Method in class org.codehaus.activemq.ActiveMQPrefetchPolicy
 
setQueuePrefix(String) - Method in class org.codehaus.activemq.jndi.ActiveMQInitialContextFactory
 
setRead(boolean) - Method in class org.codehaus.activemq.service.impl.MessagePointer
 
setReadOnly(boolean) - Method in class org.codehaus.activemq.journal.impl.Segment
 
setReadOnly(boolean) - Method in class org.codehaus.activemq.message.ActiveMQMessage
set the message readOnly
setReceipt(Receipt) - Method in class org.codehaus.activemq.message.ReceiptHolder
Set the Receipt for this holder
setReceiptRequired(boolean) - Method in class org.codehaus.activemq.message.AbstractPacket
Set if a Recipt if required on receiving this Packet
setReceiptRequired(boolean) - Method in interface org.codehaus.activemq.message.Packet
Set if a Recipt if required on receiving this Packet
setReceiveCapacity(int) - Method in class org.codehaus.activemq.transport.vm.VmTransportChannel
 
setReceiveChannel(Channel) - Method in class org.codehaus.activemq.transport.vm.VmTransportChannel
 
setReceiveHttpClient(HttpClient) - Method in class org.codehaus.activemq.transport.http.HttpClientTransportChannel
 
setReconnectSleepTime(long) - Method in class org.codehaus.activemq.transport.NetworkChannel
 
setRedelivered(boolean) - Method in class org.codehaus.activemq.service.impl.MessagePointer
 
setRedeliveryPolicy(RedeliveryPolicy) - Method in interface org.codehaus.activemq.broker.Broker
 
setRedeliveryPolicy(RedeliveryPolicy) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
 
setRedeliveryPolicy(RedeliveryPolicy) - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
setRedeliveryPolicy(RedeliveryPolicy) - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
 
setReference(Reference) - Method in class org.codehaus.activemq.ra.ActiveMQConnectionFactory
 
setRemoteBrokerName(String) - Method in class org.codehaus.activemq.transport.NetworkChannel
 
setRemotePassword(String) - Method in class org.codehaus.activemq.transport.DiscoveryNetworkConnector
 
setRemotePassword(String) - Method in class org.codehaus.activemq.transport.DiscoveryTransportChannel
 
setRemotePassword(String) - Method in class org.codehaus.activemq.transport.NetworkChannel
 
setRemoteSession(Session) - Method in class org.codehaus.activemq.transport.NetworkMessageBridge
 
setRemoteURI(URI) - Method in class org.codehaus.activemq.transport.TransportStatusEvent
 
setRemoteUserName(String) - Method in class org.codehaus.activemq.transport.DiscoveryNetworkConnector
 
setRemoteUserName(String) - Method in class org.codehaus.activemq.transport.DiscoveryTransportChannel
 
setRemoteUserName(String) - Method in class org.codehaus.activemq.transport.NetworkChannel
 
setResource(Resource) - Method in class org.codehaus.activemq.spring.SpringBrokerContainerFactory
 
setResourceAdapter(ResourceAdapter) - Method in class org.codehaus.activemq.ra.ActiveMQActivationSpec
 
setResourceAdapter(ResourceAdapter) - Method in class org.codehaus.activemq.ra.ActiveMQManagedConnectionFactory
 
setResourceName(String) - Method in class org.codehaus.activemq.message.CapacityInfo
 
setResponseHeaders(HttpServletResponse, Message) - Method in class org.codehaus.activemq.web.MessageServlet
 
setResult(int) - Method in class org.codehaus.activemq.message.IntResponseReceipt
 
setResult(Serializable) - Method in class org.codehaus.activemq.message.ResponseReceipt
 
setResultBytes(byte[]) - Method in class org.codehaus.activemq.message.ResponseReceipt
 
setReuseMessageId(boolean) - Method in class org.codehaus.activemq.ActiveMQMessageProducer
 
setRight(Expression) - Method in class org.codehaus.activemq.filter.BinaryExpression
 
setRight(Expression) - Method in class org.codehaus.activemq.filter.UnaryExpression
 
setRoundingFactor(int) - Method in class org.codehaus.activemq.capacity.BasicCapacityMonitor
Set the rounding factor (between 1-100)
setRoundingFactor(int) - Method in interface org.codehaus.activemq.capacity.CapacityMonitor
Set the rounding factor (between 1-100)
setRoundingFactor(int) - Method in class org.codehaus.activemq.capacity.DelegateCapacityMonitor
Set the rounding factor (between 1-100)
setSecurityAdapter(SecurityAdapter) - Method in interface org.codehaus.activemq.broker.Broker
Sets the security adapter used to authenticate and authorize access to JMS resources
setSecurityAdapter(SecurityAdapter) - Method in interface org.codehaus.activemq.broker.BrokerContainer
Sets the security adapter used to authenticate and authorize access to JMS resources
setSecurityAdapter(SecurityAdapter) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
 
setSecurityAdapter(SecurityAdapter) - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
setSecurityCredentials(String) - Method in class org.codehaus.activemq.util.JndiJmsLogAppender
 
setSecurityPrincipalName(String) - Method in class org.codehaus.activemq.util.JndiJmsLogAppender
 
setSeed(long) - Method in class org.codehaus.activemq.transport.reliable.SMLCGRandom
Set the seed for the random generator
setSegmentIndexAndOffset(byte, int) - Method in class org.codehaus.activemq.journal.impl.RecordLocationImpl
 
setSelector(String) - Method in class org.codehaus.activemq.message.ConsumerInfo
 
setSelector(String) - Method in class org.codehaus.activemq.service.SubscriberEntry
 
setSendCapacity(int) - Method in class org.codehaus.activemq.transport.vm.VmTransportChannel
 
setSendChannel(Channel) - Method in class org.codehaus.activemq.transport.vm.VmTransportChannel
 
setSendCloseTimeout(int) - Method in class org.codehaus.activemq.ActiveMQConnection
 
setSendConnectionInfoTimeout(int) - Method in class org.codehaus.activemq.ActiveMQConnection
 
setSendHttpClient(HttpClient) - Method in class org.codehaus.activemq.transport.http.HttpClientTransportChannel
 
setSequence(long) - Method in class org.codehaus.activemq.journal.impl.RecordLocationImpl
 
setSequenceDataType(String) - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
setSequenceNumber(Object) - Method in class org.codehaus.activemq.service.MessageIdentity
 
setServerSide(boolean) - Method in interface org.codehaus.activemq.transport.TransportChannel
set the server flag
setServerSide(boolean) - Method in class org.codehaus.activemq.transport.TransportChannelSupport
 
setServerUrl(String) - Method in class org.codehaus.activemq.ra.ActiveMQConnectionRequestInfo
 
setServerUrl(String) - Method in class org.codehaus.activemq.ra.ActiveMQResourceAdapter
 
setSession(Session) - Method in class org.codehaus.activemq.util.JmsLogAppenderSupport
 
setSessionConsumerDispatchState(int) - Method in class org.codehaus.activemq.ActiveMQSession
 
setSessionId(String) - Method in class org.codehaus.activemq.ActiveMQSession
 
setSessionId(String) - Method in class org.codehaus.activemq.message.ConsumerInfo
 
setSessionId(String) - Method in class org.codehaus.activemq.message.ProducerInfo
 
setSessionId(String) - Method in class org.codehaus.activemq.message.SessionInfo
 
setShort(String, short) - Method in class org.codehaus.activemq.message.ActiveMQMapMessage
Sets a short value with the specified name into the Map.
setShortProperty(String, short) - Method in class org.codehaus.activemq.message.ActiveMQMessage
Sets a short property value with the specified name into the message.
setSoTimeout(int) - Method in class org.codehaus.activemq.transport.tcp.TcpTransportChannel
 
setStartTime(long) - Method in class org.codehaus.activemq.ActiveMQSession
 
setStartTime(long) - Method in class org.codehaus.activemq.message.BrokerInfo
 
setStartTime(long) - Method in class org.codehaus.activemq.message.ConnectionInfo
 
setStartTime(long) - Method in class org.codehaus.activemq.message.ConsumerInfo
 
setStartTime(long) - Method in class org.codehaus.activemq.message.ProducerInfo
 
setStartTime(long) - Method in class org.codehaus.activemq.message.SessionInfo
 
setStarted(boolean) - Method in class org.codehaus.activemq.message.ConnectionInfo
 
setStarted(boolean) - Method in class org.codehaus.activemq.message.ConsumerInfo
 
setStarted(boolean) - Method in class org.codehaus.activemq.message.ProducerInfo
 
setStarted(boolean) - Method in class org.codehaus.activemq.message.SessionInfo
 
setState(byte) - Method in class org.codehaus.activemq.service.impl.AbstractTransaction
 
setStats(JMSDestinationStats) - Method in class org.codehaus.activemq.message.ActiveMQDestination
 
setString(String, String) - Method in class org.codehaus.activemq.message.ActiveMQMapMessage
Sets a String value with the specified name into the Map.
setStringProperty(String, String) - Method in class org.codehaus.activemq.message.ActiveMQMessage
Sets a String property value with the specified name into the message.
setSubscriberEntry(ConsumerInfo, SubscriberEntry) - Method in interface org.codehaus.activemq.store.TopicMessageStore
Inserts or updates the subscriber info due to a subscription change
setSubscriberEntry(ConsumerInfo, SubscriberEntry) - Method in class org.codehaus.activemq.store.bdb.BDbTopicMessageStore
 
setSubscriberEntry(ConsumerInfo, SubscriberEntry) - Method in class org.codehaus.activemq.store.bdbn.BDbTopicMessageStore
 
setSubscriberEntry(ConsumerInfo, SubscriberEntry) - Method in class org.codehaus.activemq.store.cache.CacheTopicMessageStore
 
setSubscriberEntry(ConsumerInfo, SubscriberEntry) - Method in class org.codehaus.activemq.store.jdbc.JDBCTopicMessageStore
 
setSubscriberEntry(ConsumerInfo, SubscriberEntry) - Method in class org.codehaus.activemq.store.jdbm.JdbmTopicMessageStore
 
setSubscriberEntry(ConsumerInfo, SubscriberEntry) - Method in class org.codehaus.activemq.store.vm.VMTopicMessageStore
 
setSubscriberID(int) - Method in class org.codehaus.activemq.service.SubscriberEntry
 
setSubscriberName(String) - Method in class org.codehaus.activemq.message.DurableUnsubscribe
 
setSubscriberName(String) - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
 
setSubscriptionIdDataType(String) - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
setSync(boolean) - Method in class org.codehaus.activemq.store.journal.JournalPersistenceAdapter
 
setTable(Hashtable) - Method in class org.codehaus.activemq.message.ActiveMQMapMessage
set the table body
setTablePrefix(String) - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
setTempDir(File) - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
setText(String) - Method in class org.codehaus.activemq.message.ActiveMQTextMessage
Sets the string containing this message's data.
setThreadsWaitingForceThreshold(int) - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
setTimeToLive(long) - Method in class org.codehaus.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.
setTopicPrefetch(int) - Method in class org.codehaus.activemq.ActiveMQPrefetchPolicy
 
setTopicPrefix(String) - Method in class org.codehaus.activemq.jndi.ActiveMQInitialContextFactory
 
setTransactionConfig(TransactionConfig) - Method in class org.codehaus.activemq.store.bdb.BDbPersistenceAdapter
 
setTransactionId(String) - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
setTransactionId(String) - Method in class org.codehaus.activemq.message.MessageAck
 
setTransactionId(String) - Method in class org.codehaus.activemq.message.TransactionInfo
 
setTransactionLog(Logger) - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
setTransactionManager(TransactionManager) - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
setTransactionTimeout(int) - Method in class org.codehaus.activemq.ActiveMQXASession
 
setTransactionTimeout(int) - Method in class org.codehaus.activemq.message.XATransactionInfo
 
setTransientConsumed(boolean) - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
setTransportChannelListener(TransportChannelListener) - Method in class org.codehaus.activemq.transport.NetworkConnector
 
setTransportChannelListener(TransportChannelListener) - Method in interface org.codehaus.activemq.transport.TransportChannel
A listener to be notified when the channel is removed
setTransportChannelListener(TransportChannelListener) - Method in class org.codehaus.activemq.transport.TransportChannelSupport
 
setTransportChannelListener(TransportChannelListener) - Method in interface org.codehaus.activemq.transport.TransportServerChannel
Registers the listener to be used when new clients connect or disconnect
setTransportChannelListener(TransportChannelListener) - Method in class org.codehaus.activemq.transport.TransportServerChannelSupport
 
setTransportConnected(boolean) - Method in class org.codehaus.activemq.transport.TransportChannelSupport
 
setTransportConnectors(List) - Method in interface org.codehaus.activemq.broker.BrokerContainer
 
setTransportConnectors(List) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
 
setTxTableName(String) - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
setType(int) - Method in class org.codehaus.activemq.message.TransactionInfo
 
setType(int) - Method in class org.codehaus.activemq.message.XATransactionInfo
 
setType(String) - Method in class org.codehaus.activemq.transport.zeroconf.ZeroconfDiscoveryAgent
 
setUri(String) - Method in class org.codehaus.activemq.transport.NetworkChannel
set the uri of the broker(s) this channel is connected to
setUri(String) - Method in class org.codehaus.activemq.util.JmsLogAppender
 
setUris(List) - Method in class org.codehaus.activemq.transport.composite.CompositeTransportChannel
 
setUrl(String) - Method in class org.codehaus.activemq.gbean.ActiveMQConnectorGBean
 
setUrl(String) - Method in class org.codehaus.activemq.transport.TransportServerChannelSupport
 
setUrlPkgPrefixes(String) - Method in class org.codehaus.activemq.util.JndiJmsLogAppender
 
setUseAsyncSend(boolean) - Method in class org.codehaus.activemq.ActiveMQConnection
 
setUseAsyncSend(boolean) - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
 
setUseAsyncSend(boolean) - Method in class org.codehaus.activemq.transport.tcp.TcpTransportChannel
 
setUseAsyncSend(boolean) - Method in class org.codehaus.activemq.transport.tcp.TcpTransportServerChannel
 
setUseEmbeddedBroker(boolean) - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
Allows embedded brokers to be associated with a connection factory
setUserName(String) - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
 
setUserName(String) - Method in class org.codehaus.activemq.message.ConnectionInfo
 
setUserName(String) - Method in class org.codehaus.activemq.ra.ActiveMQConnectionRequestInfo
 
setUserName(String) - Method in class org.codehaus.activemq.ra.ActiveMQResourceAdapter
 
setUserName(String) - Method in class org.codehaus.activemq.util.JmsLogAppender
 
setUserName(String) - Method in class org.codehaus.activemq.util.JndiJmsLogAppender
 
setValueLimit(long) - Method in class org.codehaus.activemq.capacity.BasicCapacityMonitor
set a new value limit for the CapacityMonitor
setValueLimit(long) - Method in interface org.codehaus.activemq.capacity.CapacityMonitor
set a new value limit for the CapacityMonitor
setValueLimit(long) - Method in class org.codehaus.activemq.capacity.DelegateCapacityMonitor
set a new value limit for the CapacityMonitor
setVersion(int) - Method in class org.codehaus.activemq.message.WireFormatInfo
 
setWeight(int) - Method in class org.codehaus.activemq.transport.zeroconf.ZeroconfDiscoveryAgent
 
setWireFormat(WireFormat) - Method in class org.codehaus.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(WireFormat) - Method in class org.codehaus.activemq.gbean.ActiveMQConnectorGBean
 
setWireFormat(WireFormat) - Method in class org.codehaus.activemq.store.bdb.BDbPersistenceAdapter
 
setWireFormat(WireFormat) - Method in class org.codehaus.activemq.store.jdbc.JDBCPersistenceAdapter
 
setWireFormat(WireFormat) - Method in class org.codehaus.activemq.store.journal.JournalPersistenceAdapter
 
setWireFormat(TextWireFormat) - Method in class org.codehaus.activemq.transport.http.HttpTransportChannelSupport
 
setWireFormat(TextWireFormat) - Method in class org.codehaus.activemq.transport.http.HttpTransportConnector
 
setWireFormatVersion(int) - Method in class org.codehaus.activemq.message.ConnectionInfo
 
setXA(Boolean) - Method in class org.codehaus.activemq.ra.ActiveMQResourceAdapter
 
setXStream(XStream) - Method in class org.codehaus.activemq.transport.xstream.XStreamWireFormat
 
setXa(boolean) - Method in class org.codehaus.activemq.ra.ActiveMQConnectionRequestInfo
Enables or disables whether XA connections should be created
setXaTransacted(boolean) - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
setXaTransacted(boolean) - Method in class org.codehaus.activemq.message.MessageAck
 
setXid(ActiveMQXid) - Method in class org.codehaus.activemq.message.XATransactionInfo
 
setXidDataType(String) - Method in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
shallowCopy() - Method in class org.codehaus.activemq.message.ActiveMQBytesMessage
 
shallowCopy() - Method in class org.codehaus.activemq.message.ActiveMQMapMessage
 
shallowCopy() - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
shallowCopy() - Method in class org.codehaus.activemq.message.ActiveMQObjectMessage
 
shallowCopy() - Method in class org.codehaus.activemq.message.ActiveMQStreamMessage
 
shallowCopy() - Method in class org.codehaus.activemq.message.ActiveMQTextMessage
 
size() - Method in interface org.codehaus.activemq.message.util.BoundedPacketQueue
 
size() - Method in class org.codehaus.activemq.message.util.DataContainer
 
size() - Method in class org.codehaus.activemq.message.util.MemoryBoundedQueue
 
size() - Method in class org.codehaus.activemq.message.util.SpooledBoundedPacketQueue
 
size() - Method in class org.codehaus.activemq.ra.CircularQueue
 
size() - Method in interface org.codehaus.activemq.service.QueueList
Returns the number of elements in this list.
size() - Method in class org.codehaus.activemq.service.impl.DefaultQueueList
 
size - Variable in class org.codehaus.activemq.service.impl.QueueListSupport.Header
 
size() - Method in class org.codehaus.activemq.service.impl.QueueListSupport
 
socket - Variable in class org.codehaus.activemq.transport.tcp.TcpTransportChannel
 
socket - Variable in class org.codehaus.activemq.transport.udp.UdpTransportChannel
 
specialConstructor - Variable in class org.codehaus.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.codehaus.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.
ss - Variable in class org.codehaus.activemq.ra.ActiveMQAsfEndpointWorker.ServerSessionPoolImpl
 
start() - Method in class org.codehaus.activemq.ActiveMQConnection
Starts (or restarts) a connection's delivery of incoming messages.
start() - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
 
start() - Method in class org.codehaus.activemq.ActiveMQSession
Start this Session
start() - Method in class org.codehaus.activemq.ActiveMQSessionExecutor
 
start(Xid, int) - Method in class org.codehaus.activemq.ActiveMQXASession
Associates a transaction with the resource.
start() - Method in class org.codehaus.activemq.broker.impl.BrokerClientImpl
start consuming messages
start() - Method in class org.codehaus.activemq.broker.impl.BrokerConnectorImpl
start the Broker
start() - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
start the Container
start() - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
Start this Service
start() - Method in interface org.codehaus.activemq.message.util.BoundedPacketQueue
enable dequeueing
start() - Method in class org.codehaus.activemq.message.util.MemoryBoundedQueue
enable dequeueing
start() - Method in class org.codehaus.activemq.message.util.SpooledBoundedPacketQueue
enable dequeueing
start() - Method in class org.codehaus.activemq.ra.ActiveMQAsfEndpointWorker.ServerSessionImpl
 
start() - Method in class org.codehaus.activemq.ra.ActiveMQAsfEndpointWorker
 
start() - Method in class org.codehaus.activemq.ra.ActiveMQBaseEndpointWorker
 
start() - Method in class org.codehaus.activemq.ra.ActiveMQPollingEndpointWorker
 
start(BootstrapContext) - Method in class org.codehaus.activemq.ra.ActiveMQResourceAdapter
 
start() - Method in class org.codehaus.activemq.ra.JMSConnectionProxy
 
start() - Method in interface org.codehaus.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.codehaus.activemq.service.Service
Called to start the service
start() - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
start working
start() - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageManager
start the manager
start() - Method in class org.codehaus.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
start working
start() - Method in class org.codehaus.activemq.service.boundedvm.TransientTopicBoundedMessageManager
start the manager
start() - Method in class org.codehaus.activemq.service.impl.DispatchWorker
start the DispatchWorker
start() - Method in class org.codehaus.activemq.service.impl.DispatcherImpl
start the DispatchWorker
start() - Method in class org.codehaus.activemq.service.impl.DurableQueueMessageContainer
 
start() - Method in class org.codehaus.activemq.service.impl.DurableTopicMessageContainer
 
start() - Method in class org.codehaus.activemq.service.impl.MessageContainerManagerSupport
 
start() - Method in class org.codehaus.activemq.service.impl.ProxyMessageContainerManager
 
start() - Method in class org.codehaus.activemq.service.impl.TransactionManagerImpl
 
start() - Method in class org.codehaus.activemq.store.bdb.BDbMessageStore
 
start() - Method in class org.codehaus.activemq.store.bdb.BDbPersistenceAdapter
 
start() - Method in class org.codehaus.activemq.store.bdb.BDbPreparedTransactionStore
 
start() - Method in class org.codehaus.activemq.store.bdbn.BDbMessageStore
 
start() - Method in class org.codehaus.activemq.store.bdbn.BDbPersistenceAdapter
 
start() - Method in class org.codehaus.activemq.store.cache.CacheMessageStore
 
start() - Method in class org.codehaus.activemq.store.cache.CachePersistenceAdapter
 
start() - Method in class org.codehaus.activemq.store.howl.HowlMessageStore
 
start() - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
start() - Method in class org.codehaus.activemq.store.jdbc.JDBCMessageStore
 
start() - Method in class org.codehaus.activemq.store.jdbc.JDBCPersistenceAdapter
 
start() - Method in class org.codehaus.activemq.store.jdbc.JDBCPreparedTransactionStore
 
start() - Method in class org.codehaus.activemq.store.jdbm.JdbmMessageStore
 
start() - Method in class org.codehaus.activemq.store.jdbm.JdbmPersistenceAdapter
 
start() - Method in class org.codehaus.activemq.store.jdbm.JdbmPreparedTransactionStore
 
start() - Method in class org.codehaus.activemq.store.journal.JournalMessageStore
 
start() - Method in class org.codehaus.activemq.store.journal.JournalPersistenceAdapter
 
start() - Method in class org.codehaus.activemq.store.vm.VMMessageStore
 
start() - Method in class org.codehaus.activemq.store.vm.VMPersistenceAdapter
 
start() - Method in class org.codehaus.activemq.store.vm.VMPreparedTransactionStoreImpl
 
start() - Method in class org.codehaus.activemq.transport.DiscoveryNetworkConnector
 
start() - Method in class org.codehaus.activemq.transport.DiscoveryTransportChannel
 
start() - Method in class org.codehaus.activemq.transport.NetworkChannel
Start the channel
start() - Method in class org.codehaus.activemq.transport.NetworkConnector
 
start() - Method in class org.codehaus.activemq.transport.NetworkMessageBridge
start the bridge
start() - Method in interface org.codehaus.activemq.transport.TransportChannel
start listeneing for events
start() - Method in interface org.codehaus.activemq.transport.TransportServerChannel
start listeneing for events
start() - Method in class org.codehaus.activemq.transport.TransportServerChannelSupport
 
start() - Method in class org.codehaus.activemq.transport.composite.CompositeTransportChannel
 
start() - Method in class org.codehaus.activemq.transport.ember.EmberTransportChannel
start listeneing for events
start() - Method in class org.codehaus.activemq.transport.ember.EmberTransportServerChannel
start listeneing for events
start() - Method in class org.codehaus.activemq.transport.gnet.GTransportChannel
start listeneing for events
start() - Method in class org.codehaus.activemq.transport.gnet.GTransportServerChannel
start listeneing for events
start() - Method in class org.codehaus.activemq.transport.http.HttpServerTransportChannel
 
start() - Method in class org.codehaus.activemq.transport.http.HttpTransportChannelSupport
 
start() - Method in class org.codehaus.activemq.transport.http.HttpTransportConnector
 
start() - Method in class org.codehaus.activemq.transport.jgroups.JGroupsTransportChannel
start listeneing for events
start() - Method in class org.codehaus.activemq.transport.jrms.JRMSTransportChannel
start listeneing for events
start() - Method in class org.codehaus.activemq.transport.jrms.JRMSTransportServerChannel
start listeneing for events
start() - Method in class org.codehaus.activemq.transport.multicast.MulticastTransportServerChannel
start listeneing for events
start() - Method in class org.codehaus.activemq.transport.reliable.ReliableTransportChannel
start the connection
start() - Method in class org.codehaus.activemq.transport.tcp.TcpTransportChannel
start listeneing for events
start() - Method in class org.codehaus.activemq.transport.tcp.TcpTransportServerChannel
 
start() - Method in class org.codehaus.activemq.transport.udp.UdpTransportChannel
start listeneing for events
start() - Method in class org.codehaus.activemq.transport.udp.UdpTransportServerChannel
start listeneing for events
start() - Method in class org.codehaus.activemq.transport.vm.VmTransportChannel
 
start() - Method in class org.codehaus.activemq.transport.vm.VmTransportServerChannel
start listeneing for events
start() - Method in class org.codehaus.activemq.transport.zeroconf.ZeroconfDiscoveryAgent
 
start() - Method in class org.codehaus.activemq.web.WebClient
 
startThread() - Method in class org.codehaus.activemq.transport.http.HttpTransportChannelSupport
 
startTime - Variable in class org.codehaus.activemq.ActiveMQMessageConsumer
 
startTime - Variable in class org.codehaus.activemq.message.ConnectionInfo
 
startTransaction(BrokerClient, String) - Method in interface org.codehaus.activemq.broker.Broker
start a transaction
startTransaction(BrokerClient, ActiveMQXid) - Method in interface org.codehaus.activemq.broker.Broker
 
startTransaction(BrokerClient, String) - Method in interface org.codehaus.activemq.broker.BrokerConnector
Start a transaction from the Client session
startTransaction(BrokerClient, ActiveMQXid) - Method in interface org.codehaus.activemq.broker.BrokerConnector
Start an XA transaction
startTransaction(BrokerClient, String) - Method in interface org.codehaus.activemq.broker.BrokerContainer
Start a transaction from the Client session
startTransaction(BrokerClient, ActiveMQXid) - Method in interface org.codehaus.activemq.broker.BrokerContainer
Start an XA transaction.
startTransaction(BrokerClient, String) - Method in class org.codehaus.activemq.broker.impl.BrokerConnectorImpl
Start a transaction from the Client session
startTransaction(BrokerClient, ActiveMQXid) - Method in class org.codehaus.activemq.broker.impl.BrokerConnectorImpl
Start an XA transaction.
startTransaction(BrokerClient, String) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
Start a transaction from the Client session
startTransaction(BrokerClient, ActiveMQXid) - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
Start an XA transaction.
startTransaction(BrokerClient, String) - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
Start a transaction.
startTransaction(BrokerClient, ActiveMQXid) - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
Starts an XA Transaction.
started - Variable in class org.codehaus.activemq.message.ConnectionInfo
 
started - Variable in class org.codehaus.activemq.transport.composite.CompositeTransportChannel
 
statementProvider - Variable in class org.codehaus.activemq.store.jdbc.adapter.DefaultJDBCAdapter
 
staticFlag - Static variable in class org.codehaus.activemq.selector.SimpleCharStream
 
statusChanged(TransportStatusEvent) - Method in class org.codehaus.activemq.ActiveMQConnection
handle disconnect/reconnect events
statusChanged(TransportStatusEvent) - Method in interface org.codehaus.activemq.transport.TransportStatusEventListener
called when the status of a transport channel changes
stop() - Method in class org.codehaus.activemq.ActiveMQConnection
Temporarily stops a connection's delivery of incoming messages.
stop() - Method in class org.codehaus.activemq.ActiveMQConnectionFactory
A hook to allow any embedded JMS Broker's to be closed down
stop() - Method in class org.codehaus.activemq.ActiveMQSession
Stop this Session
stop() - Method in class org.codehaus.activemq.ActiveMQSessionExecutor
 
stop() - Method in class org.codehaus.activemq.broker.impl.BrokerClientImpl
stop consuming messages
stop() - Method in class org.codehaus.activemq.broker.impl.BrokerConnectorImpl
Stop the Broker
stop() - Method in class org.codehaus.activemq.broker.impl.BrokerContainerImpl
Stop the Container
stop() - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
stop this Service
stop() - Method in interface org.codehaus.activemq.message.util.BoundedPacketQueue
disable dequeueing
stop() - Method in class org.codehaus.activemq.message.util.MemoryBoundedQueue
disable dequeueing
stop() - Method in class org.codehaus.activemq.message.util.SpooledBoundedPacketQueue
disable dequeueing
stop() - Method in class org.codehaus.activemq.ra.ActiveMQAsfEndpointWorker
 
stop() - Method in class org.codehaus.activemq.ra.ActiveMQBaseEndpointWorker
 
stop() - Method in class org.codehaus.activemq.ra.ActiveMQPollingEndpointWorker
 
stop() - Method in class org.codehaus.activemq.ra.ActiveMQResourceAdapter
 
stop() - Method in class org.codehaus.activemq.ra.JMSConnectionProxy
 
stop() - Method in interface org.codehaus.activemq.service.Service
Called to shutdown the service
stop() - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
stop working
stop() - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageManager
stop the manager
stop() - Method in class org.codehaus.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
stop working
stop() - Method in class org.codehaus.activemq.service.boundedvm.TransientTopicBoundedMessageManager
stop the manager
stop() - Method in class org.codehaus.activemq.service.impl.DispatchWorker
stop the DispatchWorker
stop() - Method in class org.codehaus.activemq.service.impl.DispatcherImpl
stop the DispatchWorker
stop() - Method in class org.codehaus.activemq.service.impl.DurableQueueMessageContainer
 
stop() - Method in class org.codehaus.activemq.service.impl.DurableTopicMessageContainer
 
stop() - Method in class org.codehaus.activemq.service.impl.MessageContainerManagerSupport
 
stop() - Method in class org.codehaus.activemq.service.impl.ProxyMessageContainerManager
 
stop() - Method in class org.codehaus.activemq.service.impl.TransactionManagerImpl
 
stop() - Method in class org.codehaus.activemq.store.bdb.BDbMessageStore
 
stop() - Method in class org.codehaus.activemq.store.bdb.BDbPersistenceAdapter
 
stop() - Method in class org.codehaus.activemq.store.bdb.BDbPreparedTransactionStore
 
stop() - Method in class org.codehaus.activemq.store.bdb.BDbTopicMessageStore
 
stop() - Method in class org.codehaus.activemq.store.bdbn.BDbMessageStore
 
stop() - Method in class org.codehaus.activemq.store.bdbn.BDbPersistenceAdapter
 
stop() - Method in class org.codehaus.activemq.store.bdbn.BDbTopicMessageStore
 
stop() - Method in class org.codehaus.activemq.store.cache.CacheMessageStore
 
stop() - Method in class org.codehaus.activemq.store.cache.CachePersistenceAdapter
 
stop() - Method in class org.codehaus.activemq.store.howl.HowlMessageStore
 
stop() - Method in class org.codehaus.activemq.store.howl.HowlPersistenceAdapter
 
stop() - Method in class org.codehaus.activemq.store.jdbc.JDBCMessageStore
 
stop() - Method in class org.codehaus.activemq.store.jdbc.JDBCPersistenceAdapter
 
stop() - Method in class org.codehaus.activemq.store.jdbc.JDBCPreparedTransactionStore
 
stop() - Method in class org.codehaus.activemq.store.jdbm.JdbmMessageStore
 
stop() - Method in class org.codehaus.activemq.store.jdbm.JdbmPersistenceAdapter
 
stop() - Method in class org.codehaus.activemq.store.jdbm.JdbmPreparedTransactionStore
 
stop() - Method in class org.codehaus.activemq.store.jdbm.JdbmTopicMessageStore
 
stop() - Method in class org.codehaus.activemq.store.journal.JournalMessageStore
 
stop() - Method in class org.codehaus.activemq.store.journal.JournalPersistenceAdapter
 
stop() - Method in class org.codehaus.activemq.store.vm.VMMessageStore
 
stop() - Method in class org.codehaus.activemq.store.vm.VMPersistenceAdapter
 
stop() - Method in class org.codehaus.activemq.store.vm.VMPreparedTransactionStoreImpl
 
stop() - Method in class org.codehaus.activemq.store.vm.VMTopicMessageStore
 
stop() - Method in class org.codehaus.activemq.transport.DiscoveryTransportChannel
 
stop() - Method in class org.codehaus.activemq.transport.NetworkChannel
stop the channel
stop() - Method in class org.codehaus.activemq.transport.NetworkConnector
 
stop() - Method in class org.codehaus.activemq.transport.NetworkMessageBridge
stop the bridge
stop() - Method in interface org.codehaus.activemq.transport.TransportChannel
close the channel
stop() - Method in class org.codehaus.activemq.transport.TransportChannelSupport
close the channel
stop() - Method in interface org.codehaus.activemq.transport.TransportServerChannel
close the ServerChannel
stop() - Method in class org.codehaus.activemq.transport.TransportServerChannelSupport
 
stop() - Method in class org.codehaus.activemq.transport.composite.CompositeTransportChannel
close the channel
stop() - Method in class org.codehaus.activemq.transport.ember.EmberTransportChannel
close the channel
stop() - Method in class org.codehaus.activemq.transport.ember.EmberTransportServerChannel
close the ServerChannel
stop() - Method in class org.codehaus.activemq.transport.gnet.GTransportChannel
close the channel
stop() - Method in class org.codehaus.activemq.transport.gnet.GTransportServerChannel
close the ServerChannel
stop() - Method in class org.codehaus.activemq.transport.http.HttpTransportChannel
 
stop() - Method in class org.codehaus.activemq.transport.http.HttpTransportChannelSupport
 
stop() - Method in class org.codehaus.activemq.transport.http.HttpTransportConnector
 
stop() - Method in class org.codehaus.activemq.transport.jgroups.JGroupsTransportChannel
close the channel
stop() - Method in class org.codehaus.activemq.transport.jrms.JRMSTransportChannel
close the channel
stop() - Method in class org.codehaus.activemq.transport.reliable.ReliableTransportChannel
stop this channel
stop() - Method in class org.codehaus.activemq.transport.tcp.TcpTransportChannel
close the channel
stop() - Method in class org.codehaus.activemq.transport.tcp.TcpTransportServerChannel
 
stop() - Method in class org.codehaus.activemq.transport.udp.UdpTransportChannel
close the channel
stop() - Method in class org.codehaus.activemq.transport.vm.VmTransportChannel
 
stop() - Method in class org.codehaus.activemq.transport.zeroconf.ZeroconfDiscoveryAgent
 
stop() - Method in class org.codehaus.activemq.web.WebClient
 
stopExecutor(Executor) - Method in class org.codehaus.activemq.transport.TransportChannelSupport
A helper method to stop the execution of an executor
stopExecutor(Executor) - Static method in class org.codehaus.activemq.util.ExecutorHelper
A helper method to stop the execution of an executor
storeSubscription(ConsumerInfo, Subscription) - Method in interface org.codehaus.activemq.service.TopicMessageContainer
Stores the persistence details in the database
storeSubscription(ConsumerInfo, Subscription) - Method in class org.codehaus.activemq.service.impl.DurableTopicMessageContainer
 
stringIdDataType - Variable in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
stringLitteral() - Method in class org.codehaus.activemq.selector.SelectorParser
 
stripLeadingSlashes(String) - Method in class org.codehaus.activemq.transport.composite.CompositeTransportChannelFactory
 
subscriptionContainer - Variable in class org.codehaus.activemq.service.impl.DurableQueueMessageContainerManager
 
subscriptionContainer - Variable in class org.codehaus.activemq.service.impl.DurableTopicMessageContainerManager
 
subscriptionIdDataType - Variable in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
subscriptionIterator() - Method in interface org.codehaus.activemq.service.SubscriptionContainer
 
subscriptionIterator() - Method in class org.codehaus.activemq.service.impl.SubscriptionContainerImpl
 
subtract(long) - Method in class org.codehaus.activemq.management.CountStatisticImpl
 
syncSendPacket(Packet) - Method in class org.codehaus.activemq.ActiveMQConnection
send a Packet through a Connection - for internal use only
syncSendPacket(Packet, int) - Method in class org.codehaus.activemq.ActiveMQConnection
Send a packet through a Connection - for internal use only
syncSendRequest(Packet) - Method in class org.codehaus.activemq.ActiveMQConnection
 

T

TCF_CLASS - Static variable in class org.codehaus.activemq.axis.ActiveMQVendorAdapter
 
TIMESTAMP_INDEX - Static variable in class org.codehaus.activemq.message.ActiveMQMessage
 
TRANSACTION_FLAGS - Static variable in class org.codehaus.activemq.store.bdbn.BDbHelper
 
TRANSACTION_ID_INDEX - Static variable in class org.codehaus.activemq.message.ActiveMQMessage
 
TRANSACTION_INFO - Static variable in interface org.codehaus.activemq.message.Packet
Transaction info
TRUE - Static variable in class org.codehaus.activemq.filter.ConstantExpression
 
TRUE - Static variable in interface org.codehaus.activemq.selector.SelectorParserConstants
 
TYPE_INDEX - Static variable in class org.codehaus.activemq.message.ActiveMQMessage
 
TcpBufferedOutputStream - class org.codehaus.activemq.transport.tcp.TcpBufferedOutputStream.
An optimized buffered outputstream for Tcp
TcpBufferedOutputStream(OutputStream) - Constructor for class org.codehaus.activemq.transport.tcp.TcpBufferedOutputStream
Constructor
TcpBufferedOutputStream(OutputStream, int) - Constructor for class org.codehaus.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 org.codehaus.activemq.transport.tcp.TcpTransportChannel.
A tcp implementation of a TransportChannel
TcpTransportChannel(WireFormat) - Constructor for class org.codehaus.activemq.transport.tcp.TcpTransportChannel
Construct basic helpers
TcpTransportChannel(WireFormat, URI) - Constructor for class org.codehaus.activemq.transport.tcp.TcpTransportChannel
Connect to a remote Node - e.g.
TcpTransportChannel(WireFormat, URI, URI) - Constructor for class org.codehaus.activemq.transport.tcp.TcpTransportChannel
Connect to a remote Node - e.g.
TcpTransportChannel(WireFormat, Socket, Executor) - Constructor for class org.codehaus.activemq.transport.tcp.TcpTransportChannel
 
TcpTransportChannelFactory - class org.codehaus.activemq.transport.tcp.TcpTransportChannelFactory.
A tcp implementation of a TransportChannelFactory
TcpTransportChannelFactory() - Constructor for class org.codehaus.activemq.transport.tcp.TcpTransportChannelFactory
 
TcpTransportServerChannel - class org.codehaus.activemq.transport.tcp.TcpTransportServerChannel.
Binds to a well known port and listens for Sockets ...
TcpTransportServerChannel(WireFormat, URI) - Constructor for class org.codehaus.activemq.transport.tcp.TcpTransportServerChannel
Default Constructor
TcpTransportServerChannel(WireFormat, ServerSocket) - Constructor for class org.codehaus.activemq.transport.tcp.TcpTransportServerChannel
 
TcpTransportServerChannelFactory - class org.codehaus.activemq.transport.tcp.TcpTransportServerChannelFactory.
A tcp implementation of a TransportServerChannelFactory
TcpTransportServerChannelFactory() - Constructor for class org.codehaus.activemq.transport.tcp.TcpTransportServerChannelFactory
 
TextWireFormat - class org.codehaus.activemq.message.TextWireFormat.
Represents a text based WireFormat such as one that uses XML packets like the XStreamWireFormat or the JabberWireFormat
TextWireFormat() - Constructor for class org.codehaus.activemq.message.TextWireFormat
 
TimeStatisticImpl - class org.codehaus.activemq.management.TimeStatisticImpl.
A time statistic implementation
TimeStatisticImpl(String, String) - Constructor for class org.codehaus.activemq.management.TimeStatisticImpl
 
TimeStatisticImpl(TimeStatisticImpl, String, String) - Constructor for class org.codehaus.activemq.management.TimeStatisticImpl
 
TimeStatisticImpl(String, String, String) - Constructor for class org.codehaus.activemq.management.TimeStatisticImpl
 
TimeoutExpiredException - exception org.codehaus.activemq.TimeoutExpiredException.
Thrown when an operation cannot be performed in the allowed time, usually a send() message
TimeoutExpiredException() - Constructor for class org.codehaus.activemq.TimeoutExpiredException
 
TimeoutExpiredException(String) - Constructor for class org.codehaus.activemq.TimeoutExpiredException
 
Token - class org.codehaus.activemq.selector.Token.
Describes the input token stream.
Token() - Constructor for class org.codehaus.activemq.selector.Token
 
TokenMgrError - error org.codehaus.activemq.selector.TokenMgrError.
 
TokenMgrError() - Constructor for class org.codehaus.activemq.selector.TokenMgrError
 
TokenMgrError(String, int) - Constructor for class org.codehaus.activemq.selector.TokenMgrError
 
TokenMgrError(boolean, int, int, int, String, char, int) - Constructor for class org.codehaus.activemq.selector.TokenMgrError
 
TopicMessageContainer - interface org.codehaus.activemq.service.TopicMessageContainer.
A Topic based MessageContainer
TopicMessageStore - interface org.codehaus.activemq.store.TopicMessageStore.
A MessageStore for durable topic subscriptions
Transaction - interface org.codehaus.activemq.service.Transaction.
A Transaction keeps track of all the tasks that must be run before and after transactional events.
TransactionContext - class org.codehaus.activemq.store.jdbc.TransactionContext.
Helps keep track of the current transaction/JDBC connection.
TransactionContext(DataSource) - Constructor for class org.codehaus.activemq.store.jdbc.TransactionContext
 
TransactionInfo - class org.codehaus.activemq.message.TransactionInfo.
Provides a infomation about a Transaction
TransactionInfo() - Constructor for class org.codehaus.activemq.message.TransactionInfo
 
TransactionInfoReader - class org.codehaus.activemq.message.TransactionInfoReader.
Reads a TransactionInfo object from a Stream
TransactionInfoReader() - Constructor for class org.codehaus.activemq.message.TransactionInfoReader
 
TransactionInfoWriter - class org.codehaus.activemq.message.TransactionInfoWriter.
Writes a TransactionInfo object to a Stream
TransactionInfoWriter() - Constructor for class org.codehaus.activemq.message.TransactionInfoWriter
 
TransactionManager - interface org.codehaus.activemq.service.TransactionManager.
A Transaction keeps track of all the tasks that must be run before and after transactional events.
TransactionManagerImpl - class org.codehaus.activemq.service.impl.TransactionManagerImpl.
 
TransactionManagerImpl(Broker, PreparedTransactionStore) - Constructor for class org.codehaus.activemq.service.impl.TransactionManagerImpl
 
TransactionTask - interface org.codehaus.activemq.service.TransactionTask.
The TransactionTask interface should be implemented by any class whose instances are intended to be executed as part of a transaction event.
TransactionTemplate - class org.codehaus.activemq.util.TransactionTemplate.
A helper class for running code with a PersistenceAdapter in a transaction.
TransactionTemplate(PersistenceAdapter) - Constructor for class org.codehaus.activemq.util.TransactionTemplate
 
TransactionType - interface org.codehaus.activemq.message.TransactionType.
 
TransientQueueBoundedMessageContainer - class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageContainer.
A MessageContainer for transient queues
TransientQueueBoundedMessageContainer(MemoryBoundedQueueManager, ActiveMQDestination) - Constructor for class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
Construct this beast
TransientQueueBoundedMessageManager - class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageManager.
A manager of MessageContainer instances
TransientQueueBoundedMessageManager(MemoryBoundedQueueManager) - Constructor for class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageManager
Constructor for TransientQueueBoundedMessageManager
TransientQueueSubscription - class org.codehaus.activemq.service.boundedvm.TransientQueueSubscription.
A holder for Transient Queue consumer info and message routing
TransientQueueSubscription(BrokerClient, MemoryBoundedQueue, Filter, ConsumerInfo) - Constructor for class org.codehaus.activemq.service.boundedvm.TransientQueueSubscription
Construct the TransientQueueSubscription
TransientSubscription - class org.codehaus.activemq.service.boundedvm.TransientSubscription.
A holder for Transient consumer info and message routing
TransientSubscription(Filter, ConsumerInfo) - Constructor for class org.codehaus.activemq.service.boundedvm.TransientSubscription
Construct the TransientSubscription
TransientTopicBoundedMessageContainer - class org.codehaus.activemq.service.boundedvm.TransientTopicBoundedMessageContainer.
A MessageContainer for transient topics One of these exists for every active Connection consuming transient Topic messages
TransientTopicBoundedMessageContainer(BrokerClient, BoundedPacketQueue) - Constructor for class org.codehaus.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
Construct this beast
TransientTopicBoundedMessageManager - class org.codehaus.activemq.service.boundedvm.TransientTopicBoundedMessageManager.
A manager of MessageContainer instances
TransientTopicBoundedMessageManager(MemoryBoundedQueueManager) - Constructor for class org.codehaus.activemq.service.boundedvm.TransientTopicBoundedMessageManager
Constructor for TransientTopicBoundedMessageManager
TransientTopicMessageContainerManager - class org.codehaus.activemq.service.impl.TransientTopicMessageContainerManager.
A default implementation of a Broker of Topic messages for transient consumers
TransientTopicMessageContainerManager(PersistenceAdapter) - Constructor for class org.codehaus.activemq.service.impl.TransientTopicMessageContainerManager
 
TransientTopicMessageContainerManager(PersistenceAdapter, SubscriptionContainer, FilterFactory, Dispatcher) - Constructor for class org.codehaus.activemq.service.impl.TransientTopicMessageContainerManager
 
TransientTopicSubscription - class org.codehaus.activemq.service.boundedvm.TransientTopicSubscription.
A holder for Transient Topic consumer info and message routing
TransientTopicSubscription(Filter, ConsumerInfo) - Constructor for class org.codehaus.activemq.service.boundedvm.TransientTopicSubscription
Construct the TransientTopicSubscription
TransportChannel - interface org.codehaus.activemq.transport.TransportChannel.
A TransportChannel is used for tranporting packets between nodes e.g.
TransportChannelFactory - interface org.codehaus.activemq.transport.TransportChannelFactory.
TransportChannelFactory for creating TransportChannels
TransportChannelFactorySupport - class org.codehaus.activemq.transport.TransportChannelFactorySupport.
Useful for implementation inheritence
TransportChannelFactorySupport() - Constructor for class org.codehaus.activemq.transport.TransportChannelFactorySupport
 
TransportChannelListener - interface org.codehaus.activemq.transport.TransportChannelListener.
Used by a server to listen for new clients coming and going and reacting accordingly
TransportChannelProvider - class org.codehaus.activemq.transport.TransportChannelProvider.
A TransportChannel is used for tranporting packets between nodes
TransportChannelProvider() - Constructor for class org.codehaus.activemq.transport.TransportChannelProvider
 
TransportChannelSupport - class org.codehaus.activemq.transport.TransportChannelSupport.
Some basic functionality, common across most transport implementations of channels
TransportChannelSupport() - Constructor for class org.codehaus.activemq.transport.TransportChannelSupport
 
TransportServerChannel - interface org.codehaus.activemq.transport.TransportServerChannel.
Represents a Server which accepts incoming client connections in the form of TransportChannels which is used inside the JMS Broker
TransportServerChannelFactory - interface org.codehaus.activemq.transport.TransportServerChannelFactory.
A TransportServerChannel is used for accepting connections from TransportChannels
TransportServerChannelProvider - class org.codehaus.activemq.transport.TransportServerChannelProvider.
locates a protocol specific TransportServerChannelFactory
TransportServerChannelProvider() - Constructor for class org.codehaus.activemq.transport.TransportServerChannelProvider
 
TransportServerChannelSupport - class org.codehaus.activemq.transport.TransportServerChannelSupport.
An abstract base class useful for implementation inheritence
TransportServerChannelSupport(URI) - Constructor for class org.codehaus.activemq.transport.TransportServerChannelSupport
 
TransportServerChannelSupport(String) - Constructor for class org.codehaus.activemq.transport.TransportServerChannelSupport
 
TransportStatusEvent - class org.codehaus.activemq.transport.TransportStatusEvent.
A TransportStatusEvent is raised when the state of the underlying transport channel changes
TransportStatusEvent() - Constructor for class org.codehaus.activemq.transport.TransportStatusEvent
Default Constructor
TransportStatusEventListener - interface org.codehaus.activemq.transport.TransportStatusEventListener.
A listener for TransportStatusEvents
tablePrefix - Variable in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 
tailKey - Variable in class org.codehaus.activemq.service.impl.QueueListSupport.Header
 
targetAndDispatch(BrokerClient, ActiveMQMessage) - Method in class org.codehaus.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
See if this container should get this message and dispatch it
throwJMSException() - Method in class org.codehaus.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
toArray() - Method in interface org.codehaus.activemq.service.QueueList
Returns an array containing all of the elements in this list in the correct order.
toArray() - Method in class org.codehaus.activemq.service.impl.DefaultQueueList
 
toArray() - Method in class org.codehaus.activemq.service.impl.QueueListSupport
 
toByteBuffer() - Method in class org.codehaus.activemq.journal.impl.RecordFooter
 
toByteBuffer() - Method in class org.codehaus.activemq.journal.impl.RecordHeader
 
toBytes() - Method in class org.codehaus.activemq.message.ActiveMQXid
 
toBytes(Packet) - Method in class org.codehaus.activemq.message.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.codehaus.activemq.message.WireFormat
A helper method which converts a packet into a byte array
toBytes() - Method in class org.codehaus.activemq.service.impl.PacketTransactionTask
 
toBytes() - Method in class org.codehaus.activemq.service.impl.XATransactionCommand
 
toLocalTransactionId() - Method in class org.codehaus.activemq.message.ActiveMQXid
 
toPacket(UpPacket) - Method in class org.codehaus.activemq.transport.gnet.GTransportChannel
 
toPlainDownPacket(Packet) - Method in class org.codehaus.activemq.transport.gnet.GTransportChannel
 
toString() - Method in class org.codehaus.activemq.ActiveMQMessageConsumer
 
toString() - Method in class org.codehaus.activemq.broker.impl.BrokerClientImpl
 
toString() - Method in class org.codehaus.activemq.capacity.CapacityMonitorEvent
 
toString() - Method in class org.codehaus.activemq.filter.BinaryExpression
 
toString() - Method in class org.codehaus.activemq.filter.ConstantExpression
 
toString(String[]) - Static method in class org.codehaus.activemq.filter.DestinationPath
Converts the paths to a single String seperated by dots.
toString() - Method in class org.codehaus.activemq.filter.MultiExpressionEvaluator.CacheExpression
 
toString() - Method in class org.codehaus.activemq.filter.PrefixDestinationFilter
 
toString() - Method in class org.codehaus.activemq.filter.PropertyExpression
 
toString() - Method in class org.codehaus.activemq.filter.UnaryExpression
 
toString() - Method in class org.codehaus.activemq.filter.WildcardDestinationFilter
 
toString() - Method in class org.codehaus.activemq.journal.JournalStatsFilter
Dumps the stats to a String.
toString() - Method in class org.codehaus.activemq.journal.howl.LongRecordLocation
 
toString() - Method in class org.codehaus.activemq.journal.impl.JournalImpl
 
toString() - Method in class org.codehaus.activemq.journal.impl.RecordLocationImpl
 
toString() - Method in class org.codehaus.activemq.journal.impl.Segment
 
toString() - Method in class org.codehaus.activemq.management.JMSConnectionStatsImpl
 
toString() - Method in class org.codehaus.activemq.management.JMSConsumerStatsImpl
 
toString() - Method in class org.codehaus.activemq.management.JMSEndpointStatsImpl
 
toString() - Method in class org.codehaus.activemq.management.JMSProducerStatsImpl
 
toString() - Method in class org.codehaus.activemq.management.JMSSessionStatsImpl
 
toString() - Method in class org.codehaus.activemq.management.StatisticImpl
 
toString() - Method in class org.codehaus.activemq.message.AbstractPacket
 
toString() - Method in class org.codehaus.activemq.message.ActiveMQDestination
 
toString() - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
toString() - Method in class org.codehaus.activemq.message.ActiveMQTextMessage
 
toString() - Method in class org.codehaus.activemq.message.ActiveMQXid
 
toString() - Method in class org.codehaus.activemq.message.CapacityInfo
 
toString() - Method in class org.codehaus.activemq.message.ConsumerInfo
 
toString() - Method in class org.codehaus.activemq.message.MessageAck
 
toString() - Method in class org.codehaus.activemq.message.Receipt
 
toString(Packet) - Method in class org.codehaus.activemq.message.TextWireFormat
Converts the packet into a String
toString() - Method in class org.codehaus.activemq.message.WireFormatInfo
 
toString() - Method in class org.codehaus.activemq.message.util.MemoryBoundedQueue
 
toString() - Method in class org.codehaus.activemq.ra.ActiveMQAsfEndpointWorker.ServerSessionImpl
 
toString() - Method in class org.codehaus.activemq.selector.Token
Returns the image.
toString() - Method in class org.codehaus.activemq.service.MessageIdentity
 
toString() - Method in class org.codehaus.activemq.service.SubscriberEntry
 
toString() - Method in class org.codehaus.activemq.service.impl.AbstractTransaction
 
toString() - Method in class org.codehaus.activemq.service.impl.SubscriptionContainerImpl
 
toString() - Method in class org.codehaus.activemq.service.impl.SubscriptionImpl
 
toString() - Method in class org.codehaus.activemq.transport.NetworkChannel
 
toString() - Method in class org.codehaus.activemq.transport.TransportStatusEvent
 
toString() - Method in class org.codehaus.activemq.transport.composite.CompositeTransportChannel
 
toString() - Method in class org.codehaus.activemq.transport.ember.EmberTransportChannel
pretty print for object
toString() - Method in class org.codehaus.activemq.transport.ember.EmberTransportServerChannel
 
toString() - Method in class org.codehaus.activemq.transport.gnet.GTransportChannel
pretty print for object
toString() - Method in class org.codehaus.activemq.transport.gnet.GTransportServerChannel
 
toString() - Method in class org.codehaus.activemq.transport.http.HttpTransportChannelSupport
 
toString() - Method in class org.codehaus.activemq.transport.jgroups.JGroupsTransportChannel
 
toString() - Method in class org.codehaus.activemq.transport.jgroups.JGroupsTransportServerChannel
 
toString() - Method in class org.codehaus.activemq.transport.jrms.JRMSTransportChannel
pretty print for object
toString() - Method in class org.codehaus.activemq.transport.jrms.JRMSTransportServerChannel
 
toString() - Method in class org.codehaus.activemq.transport.jxta.JxtaTransportChannel
pretty print for object
toString() - Method in class org.codehaus.activemq.transport.jxta.JxtaTransportServerChannel
 
toString() - Method in class org.codehaus.activemq.transport.multicast.MulticastTransportChannel
pretty print for object
toString() - Method in class org.codehaus.activemq.transport.multicast.MulticastTransportServerChannel
 
toString() - Method in class org.codehaus.activemq.transport.reliable.ReliableTransportChannel
 
toString() - Method in class org.codehaus.activemq.transport.tcp.TcpTransportChannel
pretty print for object
toString() - Method in class org.codehaus.activemq.transport.tcp.TcpTransportServerChannel
 
toString() - Method in class org.codehaus.activemq.transport.udp.UdpTransportChannel
pretty print for object
toString() - Method in class org.codehaus.activemq.transport.udp.UdpTransportServerChannel
 
toString() - Method in class org.codehaus.activemq.transport.vm.VmTransportChannel
pretty print for object
toString() - Method in class org.codehaus.activemq.transport.vm.VmTransportServerChannel
 
toString(Packet) - Method in class org.codehaus.activemq.transport.xstream.XStreamWireFormat
 
toString() - Method in class org.codehaus.activemq.transport.zeroconf.ZeroconfTransportConnector
 
token - Variable in class org.codehaus.activemq.selector.SelectorParser
 
tokenBegin - Variable in class org.codehaus.activemq.selector.SimpleCharStream
 
tokenImage - Variable in class org.codehaus.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.codehaus.activemq.selector.SelectorParserConstants
 
token_source - Variable in class org.codehaus.activemq.selector.SelectorParser
 
totalMemoryUsedSize - Variable in class org.codehaus.activemq.message.util.MemoryBoundedQueueManager
 
transacted - Variable in class org.codehaus.activemq.ra.ActiveMQBaseEndpointWorker
 
transformDestination(Destination) - Static method in class org.codehaus.activemq.ActiveMQMessageTransformation
 
transformDestination(Destination) - Static method in class org.codehaus.activemq.message.ActiveMQDestination
 
transformDocument(Document) - Method in class org.codehaus.activemq.spring.ActiveMQBeanDefinitionReader
A hook to transform the source document into a default Spring XML configuration
transformMessage(Message) - Static method in class org.codehaus.activemq.ActiveMQMessageTransformation
Creates a fast shallow copy of the current ActiveMQMessage or creates a whole new message instance from an available JMS message from another provider.
transportConnected - Variable in class org.codehaus.activemq.transport.TransportChannelSupport
 
treeBindings - Variable in class org.codehaus.activemq.jndi.ReadOnlyContext
 
tryCreatePersistenceAdapter(String, File, boolean) - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
 
txTableName - Variable in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 

U

URIHelper - class org.codehaus.activemq.util.URIHelper.
Some URI based helper methods.
URIHelper() - Constructor for class org.codehaus.activemq.util.URIHelper
 
UdpTransportChannel - class org.codehaus.activemq.transport.udp.UdpTransportChannel.
A UDP implementation of a TransportChannel
UdpTransportChannel(WireFormat) - Constructor for class org.codehaus.activemq.transport.udp.UdpTransportChannel
Construct basic helpers
UdpTransportChannel(WireFormat, URI) - Constructor for class org.codehaus.activemq.transport.udp.UdpTransportChannel
 
UdpTransportChannel(WireFormat, URI, int) - Constructor for class org.codehaus.activemq.transport.udp.UdpTransportChannel
 
UdpTransportChannel(WireFormat, DatagramSocket) - Constructor for class org.codehaus.activemq.transport.udp.UdpTransportChannel
 
UdpTransportChannel(WireFormat, DatagramSocket, int) - Constructor for class org.codehaus.activemq.transport.udp.UdpTransportChannel
 
UdpTransportChannelFactory - class org.codehaus.activemq.transport.udp.UdpTransportChannelFactory.
A UDP implementation of a TransportChannelFactory
UdpTransportChannelFactory() - Constructor for class org.codehaus.activemq.transport.udp.UdpTransportChannelFactory
 
UdpTransportServerChannel - class org.codehaus.activemq.transport.udp.UdpTransportServerChannel.
A UDP implementation of TransportServerChannel
UdpTransportServerChannel(URI) - Constructor for class org.codehaus.activemq.transport.udp.UdpTransportServerChannel
 
UdpTransportServerChannelFactory - class org.codehaus.activemq.transport.udp.UdpTransportServerChannelFactory.
A UDP implementation of a TransportServerChannelFactory
UdpTransportServerChannelFactory() - Constructor for class org.codehaus.activemq.transport.udp.UdpTransportServerChannelFactory
 
UnaryExpression - class org.codehaus.activemq.filter.UnaryExpression.
An expression which performs an operation on two expression values
UnaryExpression(Expression) - Constructor for class org.codehaus.activemq.filter.UnaryExpression
 
UnaryExpression.BooleanUnaryExpression - class org.codehaus.activemq.filter.UnaryExpression.BooleanUnaryExpression.
 
UnaryExpression.BooleanUnaryExpression(Expression) - Constructor for class org.codehaus.activemq.filter.UnaryExpression.BooleanUnaryExpression
 
UnsupportedWireFormatException - exception org.codehaus.activemq.UnsupportedWireFormatException.
This exception is raised if the wire format is not supported by the connected peer
UnsupportedWireFormatException(String) - Constructor for class org.codehaus.activemq.UnsupportedWireFormatException
Construct Exception
unaryExpr() - Method in class org.codehaus.activemq.selector.SelectorParser
 
unbind(Name) - Method in class org.codehaus.activemq.jndi.ReadOnlyContext
 
unbind(String) - Method in class org.codehaus.activemq.jndi.ReadOnlyContext
 
unconsumedMessagesDispatched - Variable in class org.codehaus.activemq.service.impl.SubscriptionImpl
 
unregisterBroker(String) - Static method in class org.codehaus.activemq.ActiveMQConnectionFactory
 
unregisterMessageInterest(MessageIdentity, MessageAck) - Method in interface org.codehaus.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
unregisterMessageInterest(MessageIdentity, MessageAck) - Method in class org.codehaus.activemq.service.boundedvm.TransientQueueBoundedMessageContainer
 
unregisterMessageInterest(MessageIdentity, MessageAck) - Method in class org.codehaus.activemq.service.boundedvm.TransientTopicBoundedMessageContainer
 
unregisterMessageInterest(MessageIdentity, MessageAck) - Method in class org.codehaus.activemq.service.impl.DurableQueueMessageContainer
Does nothing since when we receive an acknowledgement on a queue we can delete the message
unregisterMessageInterest(MessageIdentity, MessageAck) - Method in class org.codehaus.activemq.service.impl.DurableTopicMessageContainer
 
unsubscribe(String) - Method in class org.codehaus.activemq.ActiveMQSession
Unsubscribes a durable subscription that has been created by a client.
unsubscribe(String) - Method in class org.codehaus.activemq.ra.JMSSessionProxy
 
unwrapLong(Long) - Static method in class org.codehaus.activemq.service.impl.QueueListSupport
 
updateAcknowledgeStats(BrokerClient, Subscription) - Method in class org.codehaus.activemq.service.impl.MessageContainerManagerSupport
Updates the message acknowledgement stats
updateBrokerCapacity(int) - Method in interface org.codehaus.activemq.broker.BrokerClient
Update the peer Connection about the Broker's capacity for messages
updateBrokerCapacity(int) - Method in class org.codehaus.activemq.broker.impl.BrokerClientImpl
Update the peer Connection about the Broker's capacity for messages
updateHeader(QueueListSupport.Header) - Method in class org.codehaus.activemq.service.impl.QueueListSupport
Writes the header back to disk after its been changed
updateNextNode(Long, Long) - Method in class org.codehaus.activemq.service.impl.QueueListSupport
 
updateNode(QueueListSupport.Node) - Method in class org.codehaus.activemq.service.impl.QueueListSupport
Updates the node
updatePhysicalUri(URI) - Method in class org.codehaus.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.codehaus.activemq.service.impl.QueueListSupport
 
updateSampleTime() - Method in class org.codehaus.activemq.management.StatisticImpl
 
updateSendStats(BrokerClient, ActiveMQMessage) - Method in class org.codehaus.activemq.service.impl.MessageContainerManagerSupport
Updates the message sending stats
uris - Variable in class org.codehaus.activemq.transport.composite.CompositeTransportChannel
 
useAsyncSend - Variable in class org.codehaus.activemq.ActiveMQConnection
Should we use an async send for persistent non transacted messages ?
useAsyncSend - Variable in class org.codehaus.activemq.ActiveMQConnectionFactory
Should we use an async send for persistent non transacted messages ?
userName - Variable in class org.codehaus.activemq.ActiveMQConnectionFactory
 
userName - Variable in class org.codehaus.activemq.message.ConnectionInfo
 
userName - Variable in class org.codehaus.activemq.ra.ActiveMQConnectionRequestInfo
 

V

VMMessageStore - class org.codehaus.activemq.store.vm.VMMessageStore.
An implementation of MessageStore which uses a
VMMessageStore() - Constructor for class org.codehaus.activemq.store.vm.VMMessageStore
 
VMMessageStore(LinkedHashMap) - Constructor for class org.codehaus.activemq.store.vm.VMMessageStore
 
VMPersistenceAdapter - class org.codehaus.activemq.store.vm.VMPersistenceAdapter.
 
VMPersistenceAdapter() - Constructor for class org.codehaus.activemq.store.vm.VMPersistenceAdapter
 
VMPreparedTransactionStoreImpl - class org.codehaus.activemq.store.vm.VMPreparedTransactionStoreImpl.
 
VMPreparedTransactionStoreImpl() - Constructor for class org.codehaus.activemq.store.vm.VMPreparedTransactionStoreImpl
 
VMTopicMessageStore - class org.codehaus.activemq.store.vm.VMTopicMessageStore.
 
VMTopicMessageStore() - Constructor for class org.codehaus.activemq.store.vm.VMTopicMessageStore
 
VMTopicMessageStore(LinkedHashMap, Map, Map, Map) - Constructor for class org.codehaus.activemq.store.vm.VMTopicMessageStore
 
VMTransactionManager - class org.codehaus.activemq.store.vm.VMTransactionManager.
Keeps track of all the open transactions in the JMS server.
VMTransactionManager(Broker) - Constructor for class org.codehaus.activemq.store.vm.VMTransactionManager
 
VMTransactionManager(Broker, PreparedTransactionStore) - Constructor for class org.codehaus.activemq.store.vm.VMTransactionManager
 
VmTransportChannel - class org.codehaus.activemq.transport.vm.VmTransportChannel.
A VM implementation of a TransportChannel
VmTransportChannel() - Constructor for class org.codehaus.activemq.transport.vm.VmTransportChannel
 
VmTransportChannel(Channel, Channel) - Constructor for class org.codehaus.activemq.transport.vm.VmTransportChannel
 
VmTransportChannel(int) - Constructor for class org.codehaus.activemq.transport.vm.VmTransportChannel
 
VmTransportChannelFactory - class org.codehaus.activemq.transport.vm.VmTransportChannelFactory.
A VM implementation of a TransportChannelFactory
VmTransportChannelFactory() - Constructor for class org.codehaus.activemq.transport.vm.VmTransportChannelFactory
 
VmTransportServerChannel - class org.codehaus.activemq.transport.vm.VmTransportServerChannel.
A VM implementation of TransportServerChannel
VmTransportServerChannel(URI) - Constructor for class org.codehaus.activemq.transport.vm.VmTransportServerChannel
 
VmTransportServerChannelFactory - class org.codehaus.activemq.transport.vm.VmTransportServerChannelFactory.
A VM implementation of a TransportServerChannelFactory
VmTransportServerChannelFactory() - Constructor for class org.codehaus.activemq.transport.vm.VmTransportServerChannelFactory
 
validate() - Method in class org.codehaus.activemq.ra.ActiveMQActivationSpec
 
validateConsumer(ConsumerInfo) - Method in class org.codehaus.activemq.broker.impl.DefaultBroker
Ensures the consumer is valid, throwing a meaningful exception if not
value - Variable in class org.codehaus.activemq.service.impl.QueueListSupport.Node
 
vanillaToBoolean(Hashtable, String) - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
vanillaToByte(Hashtable, String) - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
vanillaToDouble(Hashtable, String) - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
vanillaToFloat(Hashtable, String) - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
vanillaToInt(Hashtable, String) - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
vanillaToLong(Hashtable, String) - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
vanillaToShort(Hashtable, String) - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
vanillaToString(Hashtable, String) - Method in class org.codehaus.activemq.message.ActiveMQMessage
 
variable() - Method in class org.codehaus.activemq.selector.SelectorParser
 
version - Variable in class org.codehaus.activemq.message.WireFormatInfo
 
view - Variable in class org.codehaus.activemq.filter.MultiExpressionEvaluator
 

W

WIRE_FORMAT_INFO - Static variable in interface org.codehaus.activemq.message.Packet
Infomation about the wire format expected
WIRE_FORMAT_VERSION - Static variable in class org.codehaus.activemq.message.DefaultWireFormat
Current wire format version for this implementation
WebClient - class org.codehaus.activemq.web.WebClient.
Represents a messaging client used from inside a web container typically stored inside a HttpSession
WebClient() - Constructor for class org.codehaus.activemq.web.WebClient
Only called by serialization
WebClient(ServletContext) - Constructor for class org.codehaus.activemq.web.WebClient
 
WebClient.SessionConsumerPair - class org.codehaus.activemq.web.WebClient.SessionConsumerPair.
 
WebClient.SessionConsumerPair() - Constructor for class org.codehaus.activemq.web.WebClient.SessionConsumerPair
 
WildcardDestinationFilter - class org.codehaus.activemq.filter.WildcardDestinationFilter.
Matches messages which contain wildcards like "A.B.*.*"
WildcardDestinationFilter(String[]) - Constructor for class org.codehaus.activemq.filter.WildcardDestinationFilter
An array of paths containing * characters
WireByteArrayInputStream - class org.codehaus.activemq.message.util.WireByteArrayInputStream.
Optimized ByteArrayInputStream that can be used more than once.
WireByteArrayInputStream(byte[]) - Constructor for class org.codehaus.activemq.message.util.WireByteArrayInputStream
Creates a WireByteArrayInputStream.
WireByteArrayInputStream(byte[], int, int) - Constructor for class org.codehaus.activemq.message.util.WireByteArrayInputStream
Creates WireByteArrayInputStream that uses buf as its buffer array.
WireByteArrayInputStream() - Constructor for class org.codehaus.activemq.message.util.WireByteArrayInputStream
Creates WireByteArrayInputStream with a minmalist byte array
WireByteArrayOutputStream - class org.codehaus.activemq.message.util.WireByteArrayOutputStream.
Optimized ByteArrayOutputStream
WireByteArrayOutputStream() - Constructor for class org.codehaus.activemq.message.util.WireByteArrayOutputStream
Creates a new byte array output stream.
WireByteArrayOutputStream(int) - Constructor for class org.codehaus.activemq.message.util.WireByteArrayOutputStream
Creates a new byte array output stream, with a buffer capacity of the specified size, in bytes.
WireFormat - class org.codehaus.activemq.message.WireFormat.
Represents a strategy of encoding packets on the wire or on disk using some kind of serialization or wire format.
WireFormat() - Constructor for class org.codehaus.activemq.message.WireFormat
 
WireFormatInfo - class org.codehaus.activemq.message.WireFormatInfo.
Describes a Connection
WireFormatInfo() - Constructor for class org.codehaus.activemq.message.WireFormatInfo
 
WireFormatInfoReader - class org.codehaus.activemq.message.WireFormatInfoReader.
Reads a ConnnectionInfo object from a Stream
WireFormatInfoReader() - Constructor for class org.codehaus.activemq.message.WireFormatInfoReader
 
WireFormatInfoWriter - class org.codehaus.activemq.message.WireFormatInfoWriter.
Writes a ConsumerInfo object to a Stream
WireFormatInfoWriter() - Constructor for class org.codehaus.activemq.message.WireFormatInfoWriter
 
waitForForce() - Method in class org.codehaus.activemq.journal.impl.BatchedWrite
 
wakeup(Subscription) - Method in interface org.codehaus.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.codehaus.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() - Method in class org.codehaus.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
wakeup(Subscription) - Method in class org.codehaus.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.codehaus.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
webClientAttribute - Static variable in class org.codehaus.activemq.web.WebClient
 
wireFormat - Variable in class org.codehaus.activemq.store.jdbc.JDBCMessageStore
 
wireFormat - Variable in class org.codehaus.activemq.transport.composite.CompositeTransportChannel
 
wireFormatVersion - Variable in class org.codehaus.activemq.message.ConnectionInfo
 
workManager - Variable in class org.codehaus.activemq.ra.ActiveMQBaseEndpointWorker
 
workPendingFlag - Variable in class org.codehaus.activemq.ra.ActiveMQAsfEndpointWorker.ServerSessionImpl
 
wrapLong(long) - Static method in class org.codehaus.activemq.service.impl.QueueListSupport
 
write(byte[], boolean) - Method in interface org.codehaus.activemq.journal.Journal
Writes a byte array record to the journal.
write(byte[], boolean) - Method in class org.codehaus.activemq.journal.JournalStatsFilter
 
write(byte[], boolean) - Method in class org.codehaus.activemq.journal.howl.HowlJournal
 
write(byte[], boolean) - Method in class org.codehaus.activemq.journal.impl.JournalImpl
 
write(byte[], boolean) - Method in class org.codehaus.activemq.journal.impl.LogFileManager
 
write(BatchedWrite) - Method in class org.codehaus.activemq.journal.impl.Segment
 
write(ByteBuffer) - Method in class org.codehaus.activemq.journal.impl.Segment
 
write(DataOutput) - Method in class org.codehaus.activemq.message.ActiveMQXid
Writes the Xid to a stream
write(byte[]) - Method in class org.codehaus.activemq.message.util.DataContainer
write a block of data into the Container
write(byte[]) - Method in class org.codehaus.activemq.message.util.FileDataBlock
Write data to the end of the block
write(int) - Method in class org.codehaus.activemq.message.util.WireByteArrayOutputStream
Writes the specified byte to this byte array output stream.
write(byte[], int, int) - Method in class org.codehaus.activemq.message.util.WireByteArrayOutputStream
Writes len bytes from the specified byte array starting at offset off to this byte array output stream.
write(int) - Method in class org.codehaus.activemq.transport.tcp.TcpBufferedOutputStream
write a byte on to the stream
write(byte[], int, int) - Method in class org.codehaus.activemq.transport.tcp.TcpBufferedOutputStream
write a byte array to the stream
writeBody(DataOutput) - Method in class org.codehaus.activemq.message.ActiveMQMapMessage
 
writeBody(DataOutput) - Method in class org.codehaus.activemq.message.ActiveMQMessage
Used serialize the message body to an output stream
writeBody(DataOutput) - Method in class org.codehaus.activemq.message.ActiveMQObjectMessage
Used serialize the message body to an output stream
writeBody(DataOutput) - Method in class org.codehaus.activemq.message.ActiveMQTextMessage
Used serialize the message body to an output stream
writeBoolean(boolean) - Method in class org.codehaus.activemq.message.ActiveMQBytesMessage
Writes a boolean to the bytes message stream as a 1-byte value.
writeBoolean(boolean) - Method in class org.codehaus.activemq.message.ActiveMQStreamMessage
Writes a boolean to the stream message.
writeByte(byte) - Method in class org.codehaus.activemq.message.ActiveMQBytesMessage
Writes a byte to the bytes message stream as a 1-byte value.
writeByte(byte) - Method in class org.codehaus.activemq.message.ActiveMQStreamMessage
Writes a byte to the stream message.
writeBytes(byte[]) - Method in class org.codehaus.activemq.message.ActiveMQBytesMessage
Writes a byte array to the bytes message stream.
writeBytes(byte[], int, int) - Method in class org.codehaus.activemq.message.ActiveMQBytesMessage
Writes a portion of a byte array to the bytes message stream.
writeBytes(byte[]) - Method in class org.codehaus.activemq.message.ActiveMQStreamMessage
Writes a byte array field to the stream message.
writeBytes(byte[], int, int) - Method in class org.codehaus.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.codehaus.activemq.message.ActiveMQXid
 
writeBytesMessage(ActiveMQBytesMessage, DataOutput) - Method in class org.codehaus.activemq.transport.jabber.JabberWireFormat
 
writeChar(char) - Method in class org.codehaus.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.codehaus.activemq.message.ActiveMQStreamMessage
Writes a char to the stream message.
writeCommand(String, boolean) - Method in class org.codehaus.activemq.store.journal.JournalPersistenceAdapter
 
writeDouble(double) - Method in class org.codehaus.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.codehaus.activemq.message.ActiveMQStreamMessage
Writes a double to the stream message.
writeExternal() - Method in class org.codehaus.activemq.journal.impl.Mark
 
writeExternal(ObjectOutput) - Method in class org.codehaus.activemq.message.ActiveMQXid
 
writeExternal(ObjectOutput) - Method in class org.codehaus.activemq.message.PacketFacade
 
writeExternal(ObjectOutput) - Method in class org.codehaus.activemq.service.SubscriberEntry
 
writeExternal(ObjectOutput) - Method in class org.codehaus.activemq.service.impl.AbstractTransaction
 
writeExternal(ObjectOutput) - Method in class org.codehaus.activemq.service.impl.MessageEntry
 
writeExternal(ObjectOutput) - Method in class org.codehaus.activemq.service.impl.PacketTransactionTask
 
writeExternal(ObjectOutput) - Method in class org.codehaus.activemq.service.impl.XATransactionCommand
 
writeExternal(ObjectOutput) - Method in class org.codehaus.activemq.web.WebClient
 
writeFailed(Throwable) - Method in class org.codehaus.activemq.journal.impl.BatchedWrite
 
writeFloat(float) - Method in class org.codehaus.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.codehaus.activemq.message.ActiveMQStreamMessage
Writes a float to the stream message.
writeInt(int) - Method in class org.codehaus.activemq.message.ActiveMQBytesMessage
Writes an int to the bytes message stream as four bytes, high byte first.
writeInt(int) - Method in class org.codehaus.activemq.message.ActiveMQStreamMessage
Writes an int to the stream message.
writeLong(long) - Method in class org.codehaus.activemq.message.ActiveMQBytesMessage
Writes a long to the bytes message stream as eight bytes, high byte first.
writeLong(long) - Method in class org.codehaus.activemq.message.ActiveMQStreamMessage
Writes a long to the stream message.
writeMapProperties(Hashtable, DataOutput) - Method in class org.codehaus.activemq.message.ActiveMQMessage
write map properties to an output stream
writeMessage(ActiveMQMessage, String, DataOutput) - Method in class org.codehaus.activemq.transport.jabber.JabberWireFormat
 
writeNullableUTF(ObjectOutput, String) - Static method in class org.codehaus.activemq.service.SubscriberEntry
 
writeObject(Object, DataOutput) - Method in class org.codehaus.activemq.message.AbstractPacketWriter
Simple (but inefficent) utility method to write an object on to a stream
writeObject(Object) - Method in class org.codehaus.activemq.message.ActiveMQBytesMessage
Writes an object to the bytes message stream.
writeObject(Object) - Method in class org.codehaus.activemq.message.ActiveMQStreamMessage
Writes an object to the stream message.
writeObjectMessage(ActiveMQObjectMessage, DataOutput) - Method in class org.codehaus.activemq.transport.jabber.JabberWireFormat
 
writePacket(Packet, DataOutput) - Method in class org.codehaus.activemq.message.AbstractPacketWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.codehaus.activemq.message.ActiveMQMessageWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.codehaus.activemq.message.BrokerInfoWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.codehaus.activemq.message.CapacityInfoRequestWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.codehaus.activemq.message.CapacityInfoWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.codehaus.activemq.message.ConnectionInfoWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.codehaus.activemq.message.ConsumerInfoWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.codehaus.activemq.message.DefaultWireFormat
Write a Packet to a DataOutput
writePacket(Packet, DataOutput, PacketWriter) - Method in class org.codehaus.activemq.message.DefaultWireFormat
 
writePacket(Packet, DataOutput) - Method in class org.codehaus.activemq.message.DurableUnsubscribeWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.codehaus.activemq.message.IntResponseReceiptWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.codehaus.activemq.message.MessageAckWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in interface org.codehaus.activemq.message.PacketWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.codehaus.activemq.message.ProducerInfoWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.codehaus.activemq.message.ReceiptWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.codehaus.activemq.message.ResponseReceiptWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.codehaus.activemq.message.SessionInfoWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.codehaus.activemq.message.TransactionInfoWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.codehaus.activemq.message.WireFormat
Writes the packet to the given output stream
writePacket(String, Packet) - Method in class org.codehaus.activemq.message.WireFormat
Writes the given package to a new datagram
writePacket(Packet, DataOutput) - Method in class org.codehaus.activemq.message.WireFormatInfoWriter
Write a Packet instance to data output stream
writePacket(Packet, DataOutput) - Method in class org.codehaus.activemq.message.XATransactionInfoWriter
Write a Packet instance to data output stream
writePacket(Packet, ObjectOutput) - Static method in class org.codehaus.activemq.service.impl.PacketTransactionTask
 
writePacket(Packet) - Method in class org.codehaus.activemq.store.howl.HowlMessageStore
Writes a message to the transaction log using the current sync mode
writePacket(String, Packet, boolean) - Method in class org.codehaus.activemq.store.journal.JournalPersistenceAdapter
 
writePacket(Packet, DataOutput) - Method in class org.codehaus.activemq.transport.jabber.JabberWireFormat
 
writePacket(Packet) - Method in class org.codehaus.activemq.transport.jgroups.JGroupsTransportChannel
writes the packet to the channel
writePacket(Packet, DataOutput) - Method in class org.codehaus.activemq.transport.xstream.XStreamWireFormat
 
writePacketToByteArray(Packet) - Method in class org.codehaus.activemq.message.AbstractPacketWriter
Serializes a Packet int a byte array
writePacketToByteArray(Packet) - Method in interface org.codehaus.activemq.message.PacketWriter
Serializes a Packet int a byte array
writeRecordFooter(DataOutput) - Method in class org.codehaus.activemq.journal.impl.RecordFooter
 
writeRecordHeader(DataOutput) - Method in class org.codehaus.activemq.journal.impl.RecordHeader
 
writeShort(short) - Method in class org.codehaus.activemq.message.ActiveMQBytesMessage
Writes a short to the bytes message stream as two bytes, high byte first.
writeShort(short) - Method in class org.codehaus.activemq.message.ActiveMQStreamMessage
Writes a short to the stream message.
writeString(String) - Method in class org.codehaus.activemq.message.ActiveMQStreamMessage
Writes a String to the stream message.
writeTask(TransactionTask, ObjectOutput) - Method in class org.codehaus.activemq.service.impl.AbstractTransaction
 
writeTask(TransactionTask, ObjectOutput) - Static method in class org.codehaus.activemq.service.impl.PacketTransactionTask
 
writeTaskList(ArrayList, ObjectOutput) - Method in class org.codehaus.activemq.service.impl.AbstractTransaction
 
writeTextMessage(ActiveMQTextMessage, DataOutput) - Method in class org.codehaus.activemq.transport.jabber.JabberWireFormat
 
writeToStream(ActiveMQDestination, DataOutput) - Static method in class org.codehaus.activemq.message.ActiveMQDestination
Write an ActiveMQDestination to a Stream
writeToStream(DataOutput) - Method in class org.codehaus.activemq.util.BitArray
write the bits to an output stream
writeUTF(String, DataOutput) - Method in class org.codehaus.activemq.message.AbstractPacketWriter
simple helper method to ensure null strings are catered for
writeUTF(String) - Method in class org.codehaus.activemq.message.ActiveMQBytesMessage
Writes a string to the bytes message stream using UTF-8 encoding in a machine-independent manner.

X

XATransactionCommand - class org.codehaus.activemq.service.impl.XATransactionCommand.
 
XATransactionCommand() - Constructor for class org.codehaus.activemq.service.impl.XATransactionCommand
This constructor is only used when deserializing from disk
XATransactionCommand(Broker, ActiveMQXid, Map, PreparedTransactionStore) - Constructor for class org.codehaus.activemq.service.impl.XATransactionCommand
 
XATransactionInfo - class org.codehaus.activemq.message.XATransactionInfo.
Provides a infomation about an XA Transaction
XATransactionInfo() - Constructor for class org.codehaus.activemq.message.XATransactionInfo
 
XATransactionInfoReader - class org.codehaus.activemq.message.XATransactionInfoReader.
Reads a TransactionInfo object from a Stream
XATransactionInfoReader() - Constructor for class org.codehaus.activemq.message.XATransactionInfoReader
 
XATransactionInfoWriter - class org.codehaus.activemq.message.XATransactionInfoWriter.
Writes a TransactionInfo object to a Stream
XATransactionInfoWriter() - Constructor for class org.codehaus.activemq.message.XATransactionInfoWriter
 
XA_RECOVER - Static variable in interface org.codehaus.activemq.message.TransactionType
Get a list of all the XIDs that are currently prepared.
XA_TRANSACTED_INDEX - Static variable in class org.codehaus.activemq.message.MessageAck
 
XA_TRANSACTION_INFO - Static variable in interface org.codehaus.activemq.message.Packet
XA Transaction info
XA_TRANS_INDEX - Static variable in class org.codehaus.activemq.message.ActiveMQMessage
 
XStreamWireFormat - class org.codehaus.activemq.transport.xstream.XStreamWireFormat.
A WireFormat implementation which uses the XStreamWireFormat() - Constructor for class org.codehaus.activemq.transport.xstream.XStreamWireFormat
 
XmlConfigHelper - class org.codehaus.activemq.XmlConfigHelper.
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.codehaus.activemq.XmlConfigHelper
 
xa - Variable in class org.codehaus.activemq.ra.ActiveMQConnectionRequestInfo
 
xaResource - Variable in class org.codehaus.activemq.ra.ActiveMQAsfEndpointWorker.ServerSessionImpl
 
xidDataType - Variable in class org.codehaus.activemq.store.jdbc.adapter.DefaultStatementProvider
 

Z

ZeroconfDiscoveryAgent - class org.codehaus.activemq.transport.zeroconf.ZeroconfDiscoveryAgent.
A DiscoveryAgent using Zeroconf via the jmDNS library
ZeroconfDiscoveryAgent() - Constructor for class org.codehaus.activemq.transport.zeroconf.ZeroconfDiscoveryAgent
 
ZeroconfTransportChannelFactory - class org.codehaus.activemq.transport.zeroconf.ZeroconfTransportChannelFactory.
 
ZeroconfTransportChannelFactory() - Constructor for class org.codehaus.activemq.transport.zeroconf.ZeroconfTransportChannelFactory
 
ZeroconfTransportConnector - class org.codehaus.activemq.transport.zeroconf.ZeroconfTransportConnector.
A Zeroconf implementation of TransportServerChannel
ZeroconfTransportConnector(WireFormat, URI) - Constructor for class org.codehaus.activemq.transport.zeroconf.ZeroconfTransportConnector
 
ZeroconfTransportConnectorFactory - class org.codehaus.activemq.transport.zeroconf.ZeroconfTransportConnectorFactory.
A Zeroconf implementation of a TransportServerChannelFactory
ZeroconfTransportConnectorFactory() - Constructor for class org.codehaus.activemq.transport.zeroconf.ZeroconfTransportConnectorFactory
 

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

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