Package | Description |
---|---|
org.apache.activemq |
The core JMS client API implementation classes.
|
org.apache.activemq.broker |
The core classes for the ActiveMQ Message Broker and its connectors.
|
org.apache.activemq.broker.ft |
Helper classes for implementing fault tolerance
|
org.apache.activemq.broker.jmx |
JMX MBeans for the broker and its core connectors.
|
org.apache.activemq.broker.region |
Region abstraction and implementations in the Broker.
|
org.apache.activemq.broker.region.cursors |
Cursors used to page persistent messages into the broker from the store
|
org.apache.activemq.broker.region.policy |
The policies which can be associated with a particular destination or wildcard.
|
org.apache.activemq.broker.region.virtual |
Implementation classes for Virtual Destinations
|
org.apache.activemq.broker.scheduler | |
org.apache.activemq.broker.util |
Some utility Broker Plugins
|
org.apache.activemq.broker.view |
Broker Plugins for visualising the current system
|
org.apache.activemq.command |
Command objects used via the Command Pattern to communicate among nodes
|
org.apache.activemq.filter |
Filter implementations for wildcards & JMS selectors
|
org.apache.activemq.kaha |
fast message persistence implementation
|
org.apache.activemq.memory.list | |
org.apache.activemq.network |
Support for federated networks of brokers.
|
org.apache.activemq.plugin | |
org.apache.activemq.security |
Plugable Security Adapter framework along with default implementations such as the JAAS implementation.
|
org.apache.activemq.state | |
org.apache.activemq.store |
The APIs which need to be implemented for persistent message stores for durable messaging
|
org.apache.activemq.store.amq |
The default Store implementation for ActiveMQ
|
org.apache.activemq.store.jdbc |
Message persistence implemented using JDBC
|
org.apache.activemq.store.journal |
Message persistence using a high performance transaction log via the Journal interface.
|
org.apache.activemq.store.kahadaptor |
kaha implementation of message persistence for the broker
|
org.apache.activemq.store.kahadb | |
org.apache.activemq.store.memory |
VM based implementation of message persistence
|
org.apache.activemq.util |
Some utility classes
|
Modifier and Type | Method and Description |
---|---|
protected boolean |
ActiveMQConnection.isDuplicate(ActiveMQDispatcher dispatcher,
Message message) |
protected void |
ActiveMQConnection.rollbackDuplicate(ActiveMQDispatcher dispatcher,
Message message) |
Modifier and Type | Method and Description |
---|---|
boolean |
ProducerBrokerExchange.canDispatch(Message messageSend)
Enforce duplicate suppression using info from persistence adapter
|
Response |
TransportConnection.processMessage(Message messageSend) |
void |
MutableBrokerFilter.send(ProducerBrokerExchange producerExchange,
Message messageSend) |
void |
BrokerFilter.send(ProducerBrokerExchange producerExchange,
Message messageSend) |
void |
EmptyBroker.send(ProducerBrokerExchange producerExchange,
Message message) |
void |
BrokerBroadcaster.send(ProducerBrokerExchange producerExchange,
Message messageSend) |
void |
ErrorBroker.send(ProducerBrokerExchange producerExchange,
Message message) |
void |
CompositeDestinationBroker.send(ProducerBrokerExchange producerExchange,
Message message) |
void |
UserIDBroker.send(ProducerBrokerExchange producerExchange,
Message messageSend) |
void |
TransactionBroker.send(ProducerBrokerExchange producerExchange,
Message message) |
Modifier and Type | Method and Description |
---|---|
void |
MasterBroker.send(ProducerBrokerExchange producerExchange,
Message message) |
protected void |
MasterBroker.sendToSlave(Message message) |
Modifier and Type | Method and Description |
---|---|
protected List<Message> |
ManagedRegionBroker.getSubscriberMessages(SubscriptionView view) |
Modifier and Type | Method and Description |
---|---|
void |
ManagedRegionBroker.send(ProducerBrokerExchange exchange,
Message message) |
Modifier and Type | Method and Description |
---|---|
Message[] |
Topic.browse() |
Message[] |
Queue.browse() |
Message[] |
DestinationFilter.browse() |
Message[] |
Destination.browse() |
Message |
IndirectMessageReference.getMessage() |
Message |
MessageReference.getMessage() |
Message |
IndirectMessageReference.getMessageHardRef() |
Message |
MessageReference.getMessageHardRef() |
Message |
Topic.loadMessage(MessageId messageId) |
Modifier and Type | Method and Description |
---|---|
protected MessageDispatch |
DurableTopicSubscription.createMessageDispatch(MessageReference node,
Message message) |
protected MessageDispatch |
PrefetchSubscription.createMessageDispatch(MessageReference node,
Message message) |
protected void |
Topic.dispatch(ConnectionContext context,
Message message) |
protected void |
PrefetchSubscription.onDispatch(MessageReference node,
Message message) |
protected void |
BaseDestination.onMessageWithNoConsumers(ConnectionContext context,
Message msg)
Provides a hook to allow messages with no consumer to be processed in
some way - such as to send to a dead letter queue or something..
|
void |
Topic.send(ProducerBrokerExchange producerExchange,
Message message) |
void |
RegionBroker.send(ProducerBrokerExchange producerExchange,
Message message) |
void |
AbstractRegion.send(ProducerBrokerExchange producerExchange,
Message messageSend) |
void |
Queue.send(ProducerBrokerExchange producerExchange,
Message message) |
void |
DestinationFilter.send(ProducerBrokerExchange context,
Message messageSend) |
void |
Destination.send(ProducerBrokerExchange producerExchange,
Message messageSend) |
void |
Region.send(ProducerBrokerExchange producerExchange,
Message message)
Send a message to the broker to using the specified destination.
|
protected void |
DestinationFilter.send(ProducerBrokerExchange context,
Message message,
ActiveMQDestination destination)
Sends a message to the given destination which may be a wildcard
|
Modifier and Type | Method and Description |
---|---|
void |
Queue.doBrowse(List<Message> browseList,
int max) |
Constructor and Description |
---|
IndirectMessageReference(Message message) |
Modifier and Type | Method and Description |
---|---|
protected Message |
FilePendingMessageCursor.getMessage(ByteSequence bs) |
Modifier and Type | Method and Description |
---|---|
protected ByteSequence |
FilePendingMessageCursor.getByteSequence(Message message) |
boolean |
AbstractStoreCursor.recoverMessage(Message message) |
boolean |
AbstractStoreCursor.recoverMessage(Message message,
boolean cached) |
Modifier and Type | Method and Description |
---|---|
Message[] |
TimedSubscriptionRecoveryPolicy.browse(ActiveMQDestination destination) |
Message[] |
QueryBasedSubscriptionRecoveryPolicy.browse(ActiveMQDestination dest) |
Message[] |
LastImageSubscriptionRecoveryPolicy.browse(ActiveMQDestination destination) |
Message[] |
FixedSizedSubscriptionRecoveryPolicy.browse(ActiveMQDestination destination) |
Message[] |
SubscriptionRecoveryPolicy.browse(ActiveMQDestination dest) |
Message[] |
NoSubscriptionRecoveryPolicy.browse(ActiveMQDestination dest) |
Message[] |
FixedCountSubscriptionRecoveryPolicy.browse(ActiveMQDestination destination) |
Modifier and Type | Method and Description |
---|---|
protected ActiveMQDestination |
IndividualDeadLetterStrategy.createDestination(Message message,
String prefix,
boolean useQueue,
Subscription subscription) |
ActiveMQDestination |
IndividualDeadLetterStrategy.getDeadLetterQueueFor(Message message,
Subscription subscription) |
ActiveMQDestination |
DeadLetterStrategy.getDeadLetterQueueFor(Message message,
Subscription subscription)
Returns the dead letter queue for the given message and subscription.
|
ActiveMQDestination |
SharedDeadLetterStrategy.getDeadLetterQueueFor(Message message,
Subscription subscription) |
boolean |
AbstractDeadLetterStrategy.isSendToDeadLetterQueue(Message message) |
boolean |
DeadLetterStrategy.isSendToDeadLetterQueue(Message message)
Allow pluggable strategy for deciding if message should be sent to a dead letter queue
for example, you might not want to ignore expired or non-persistent messages
|
boolean |
MessageQuery.validateUpdate(Message message)
Returns true if the given update is valid and does not overlap with the initial message query.
|
Modifier and Type | Method and Description |
---|---|
void |
CompositeDestinationFilter.send(ProducerBrokerExchange context,
Message message) |
void |
VirtualTopicInterceptor.send(ProducerBrokerExchange context,
Message message) |
protected void |
SelectorAwareVirtualTopicInterceptor.send(ProducerBrokerExchange context,
Message message,
ActiveMQDestination destination)
Respect the selectors of the subscriptions to ensure only matched messages are dispatched to
the virtual queues, hence there is no build up of unmatched messages on these destinations
|
Modifier and Type | Method and Description |
---|---|
void |
SchedulerBroker.send(ProducerBrokerExchange producerExchange,
Message messageSend) |
Modifier and Type | Method and Description |
---|---|
void |
DestinationPathSeparatorBroker.send(ProducerBrokerExchange producerExchange,
Message messageSend) |
void |
TimeStampingBrokerPlugin.send(ProducerBrokerExchange producerExchange,
Message message) |
void |
UDPTraceBrokerPlugin.send(ProducerBrokerExchange producerExchange,
Message messageSend) |
void |
LoggingBrokerPlugin.send(ProducerBrokerExchange producerExchange,
Message messageSend) |
Modifier and Type | Method and Description |
---|---|
void |
ConnectionDotFileInterceptor.send(ProducerBrokerExchange producerExchange,
Message messageSend) |
Modifier and Type | Class and Description |
---|---|
class |
ActiveMQBlobMessage
An implementation of
BlobMessage for out of band BLOB transfer |
class |
ActiveMQBytesMessage
A
BytesMessage object is used to send a message containing a
stream of uninterpreted bytes. |
class |
ActiveMQMapMessage
A
MapMessage object is used to send a set of name-value pairs. |
class |
ActiveMQMessage |
class |
ActiveMQObjectMessage
An
ObjectMessage object is used to send a message that
contains a serializable object in the Java programming language ("Java
object"). |
class |
ActiveMQStreamMessage
A
StreamMessage object is used to send a stream of primitive
types in the Java programming language. |
class |
ActiveMQTextMessage |
Modifier and Type | Field and Description |
---|---|
protected Message |
MessageDispatch.message |
Modifier and Type | Method and Description |
---|---|
Message |
ActiveMQBytesMessage.copy() |
Message |
ActiveMQMapMessage.copy() |
Message |
ActiveMQObjectMessage.copy() |
Message |
ActiveMQMessage.copy() |
Message |
ActiveMQTextMessage.copy() |
Message |
ActiveMQStreamMessage.copy() |
Message |
ActiveMQBlobMessage.copy() |
abstract Message |
Message.copy() |
Message |
MessageDispatch.getMessage() |
Message |
Message.getMessage() |
Message |
Message.getMessageHardRef() |
Modifier and Type | Method and Description |
---|---|
protected void |
Message.copy(Message copy) |
protected boolean |
NetworkBridgeFilter.matchesForwardingFilter(Message message,
MessageEvaluationContext mec) |
void |
MessageDispatch.setMessage(Message message) |
Constructor and Description |
---|
MessageAck(Message message,
byte ackType,
int messageCount) |
Modifier and Type | Field and Description |
---|---|
protected Message |
MessageEvaluationContext.message |
Modifier and Type | Method and Description |
---|---|
Message |
NonCachedMessageEvaluationContext.getMessage() |
Message |
MessageEvaluationContext.getMessage() |
Modifier and Type | Method and Description |
---|---|
boolean |
XPathExpression.XPathEvaluator.evaluate(Message message) |
Object |
PropertyExpression.evaluate(Message message) |
boolean |
XalanXPathEvaluator.evaluate(Message m) |
static String[] |
DestinationPath.getDestinationPaths(Message message) |
Modifier and Type | Method and Description |
---|---|
Message |
MessageMarshaller.readPayload(DataInput dataIn)
Read the entry from the RawContainer
|
Modifier and Type | Method and Description |
---|---|
void |
MessageMarshaller.writePayload(Message message,
DataOutput dataOut)
Write the payload of this entry to the RawContainer
|
Modifier and Type | Method and Description |
---|---|
Message[] |
SimpleMessageList.browse(ActiveMQDestination destination) |
Message[] |
DestinationBasedMessageList.browse(ActiveMQDestination destination) |
Message[] |
MessageList.browse(ActiveMQDestination destination) |
Modifier and Type | Method and Description |
---|---|
protected Message |
DemandForwardingBridgeSupport.configureMessage(MessageDispatch md) |
Modifier and Type | Method and Description |
---|---|
void |
ForcePersistencyModeBroker.send(ProducerBrokerExchange producerExchange,
Message messageSend)
Sets the persistence mode
|
void |
StatisticsBroker.send(ProducerBrokerExchange producerExchange,
Message messageSend)
Sets the persistence mode
|
Modifier and Type | Method and Description |
---|---|
boolean |
MessageAuthorizationPolicy.isAllowedToConsume(ConnectionContext context,
Message message)
Returns true if the given message is able to be dispatched to the connection
performing any user
|
void |
AuthorizationBroker.send(ProducerBrokerExchange producerExchange,
Message messageSend) |
Modifier and Type | Method and Description |
---|---|
Response |
ConnectionStateTracker.processMessage(Message send) |
Response |
CommandVisitor.processMessage(Message send) |
Response |
CommandVisitorAdapter.processMessage(Message send) |
Modifier and Type | Method and Description |
---|---|
Message |
ProxyMessageStore.getMessage(MessageId identity) |
Message |
MessageStore.getMessage(MessageId identity)
Looks up a message using either the String messageID or the
messageNumber.
|
Message |
ProxyTopicMessageStore.getMessage(MessageId identity) |
Modifier and Type | Method and Description |
---|---|
void |
ProxyMessageStore.addMessage(ConnectionContext context,
Message message) |
void |
MessageStore.addMessage(ConnectionContext context,
Message message)
Adds a message to the message store
|
void |
ProxyTopicMessageStore.addMessage(ConnectionContext context,
Message message) |
void |
ProxyMessageStore.addMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint) |
void |
MessageStore.addMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint)
Adds a message to the message store
|
void |
ProxyTopicMessageStore.addMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint) |
void |
AbstractMessageStore.addMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint) |
Future<Object> |
ProxyMessageStore.asyncAddQueueMessage(ConnectionContext context,
Message message) |
Future<Object> |
MessageStore.asyncAddQueueMessage(ConnectionContext context,
Message message)
Adds a message to the message store
|
Future<Object> |
ProxyTopicMessageStore.asyncAddQueueMessage(ConnectionContext context,
Message message) |
Future<Object> |
AbstractMessageStore.asyncAddQueueMessage(ConnectionContext context,
Message message) |
Future<Object> |
ProxyMessageStore.asyncAddQueueMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint) |
Future<Object> |
MessageStore.asyncAddQueueMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint)
Adds a message to the message store
|
Future<Object> |
ProxyTopicMessageStore.asyncAddQueueMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint) |
Future<Object> |
AbstractMessageStore.asyncAddQueueMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint) |
Future<Object> |
ProxyMessageStore.asyncAddTopicMessage(ConnectionContext context,
Message message) |
Future<Object> |
MessageStore.asyncAddTopicMessage(ConnectionContext context,
Message message)
Adds a message to the message store
|
Future<Object> |
ProxyTopicMessageStore.asyncAddTopicMessage(ConnectionContext context,
Message message) |
Future<Object> |
AbstractMessageStore.asyncAddTopicMessage(ConnectionContext context,
Message message) |
Future<Object> |
ProxyMessageStore.asyncAddTopicMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint) |
Future<Object> |
MessageStore.asyncAddTopicMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint)
Adds a message to the message store
|
Future<Object> |
ProxyTopicMessageStore.asyncAddTopicMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint) |
Future<Object> |
AbstractMessageStore.asyncAddTopicMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint) |
void |
TransactionRecoveryListener.recover(XATransactionId xid,
Message[] addedMessages,
MessageAck[] aks) |
boolean |
MessageRecoveryListener.recoverMessage(Message message) |
Modifier and Type | Method and Description |
---|---|
Message |
AMQMessageStore.getMessage(MessageId identity) |
Message[] |
AMQTx.getMessages() |
Modifier and Type | Method and Description |
---|---|
void |
AMQTx.add(AMQMessageStore store,
Message msg,
Location location) |
void |
AMQMessageStore.addMessage(ConnectionContext context,
Message message)
Not synchronize since the Journal has better throughput if you increase the number of concurrent writes that it
is doing.
|
boolean |
AMQMessageStore.replayAddMessage(ConnectionContext context,
Message message,
Location location) |
Modifier and Type | Method and Description |
---|---|
Message |
JDBCMessageStore.getMessage(MessageId messageId) |
Modifier and Type | Method and Description |
---|---|
void |
JDBCMessageStore.addMessage(ConnectionContext context,
Message message) |
Modifier and Type | Method and Description |
---|---|
Message |
JournalMessageStore.getMessage(MessageId identity) |
Message[] |
JournalTransactionStore.Tx.getMessages() |
Modifier and Type | Method and Description |
---|---|
void |
JournalTransactionStore.Tx.add(JournalMessageStore store,
Message msg) |
void |
JournalMessageStore.addMessage(ConnectionContext context,
Message message)
Not synchronized since the Journal has better throughput if you increase
the number of concurrent writes that it is doing.
|
void |
JournalTopicMessageStore.addMessage(ConnectionContext context,
Message message) |
void |
JournalMessageStore.replayAddMessage(ConnectionContext context,
Message message) |
Modifier and Type | Field and Description |
---|---|
protected MapContainer<MessageId,Message> |
KahaMessageStore.messageContainer |
Modifier and Type | Method and Description |
---|---|
Message |
KahaReferenceStore.getMessage(MessageId identity) |
Message |
KahaTopicReferenceStore.getMessage(MessageId identity) |
Message |
KahaMessageStore.getMessage(MessageId identity) |
Modifier and Type | Method and Description |
---|---|
protected MapContainer<MessageId,Message> |
KahaPersistenceAdapter.getMapContainer(Object id,
String containerName) |
Modifier and Type | Method and Description |
---|---|
void |
KahaReferenceStore.addMessage(ConnectionContext context,
Message message) |
void |
KahaTopicReferenceStore.addMessage(ConnectionContext context,
Message message) |
void |
KahaMessageStore.addMessage(ConnectionContext context,
Message message) |
void |
KahaTopicMessageStore.addMessage(ConnectionContext context,
Message message) |
protected boolean |
KahaMessageStore.recoverMessage(MessageRecoveryListener listener,
Message msg) |
Constructor and Description |
---|
KahaMessageStore(MapContainer<MessageId,Message> container,
ActiveMQDestination destination) |
KahaTopicMessageStore(Store store,
MapContainer<MessageId,Message> messageContainer,
ListContainer<TopicSubAck> ackContainer,
MapContainer<String,SubscriptionInfo> subsContainer,
ActiveMQDestination destination) |
Modifier and Type | Method and Description |
---|---|
Message |
TempKahaDBStore.KahaDBMessageStore.getMessage(MessageId identity) |
Message |
KahaDBStore.KahaDBMessageStore.getMessage(MessageId identity) |
Message[] |
KahaDBTransactionStore.Tx.getMessages() |
Modifier and Type | Method and Description |
---|---|
void |
TempKahaDBStore.KahaDBMessageStore.addMessage(ConnectionContext context,
Message message) |
void |
KahaDBStore.KahaDBMessageStore.addMessage(ConnectionContext context,
Message message) |
Future<Object> |
KahaDBStore.KahaDBMessageStore.asyncAddQueueMessage(ConnectionContext context,
Message message) |
Modifier and Type | Field and Description |
---|---|
protected Map<MessageId,Message> |
MemoryMessageStore.messageTable |
Modifier and Type | Method and Description |
---|---|
Message |
MemoryTransactionStore.AddMessageCommand.getMessage() |
Message |
MemoryMessageStore.getMessage(MessageId identity) |
Message[] |
MemoryTransactionStore.Tx.getMessages() |
Modifier and Type | Method and Description |
---|---|
void |
MemoryMessageStore.addMessage(ConnectionContext context,
Message message) |
void |
MemoryTopicMessageStore.addMessage(ConnectionContext context,
Message message) |
Constructor and Description |
---|
MemoryMessageStore(ActiveMQDestination destination,
Map<MessageId,Message> messageTable) |
MemoryTopicMessageStore(ActiveMQDestination destination,
Map<MessageId,Message> messageTable,
Map<SubscriptionKey,SubscriptionInfo> subscriberDatabase) |
Modifier and Type | Method and Description |
---|---|
static void |
BrokerSupport.doResend(ConnectionContext context,
Message originalMessage,
ActiveMQDestination deadLetterDestination,
boolean copy) |
static void |
BrokerSupport.resend(ConnectionContext context,
Message originalMessage,
ActiveMQDestination deadLetterDestination) |
static void |
BrokerSupport.resendNoCopy(ConnectionContext context,
Message originalMessage,
ActiveMQDestination deadLetterDestination) |
Copyright © 2005–2014. All rights reserved.