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.inteceptor |
MessageInteceptor malarky
|
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 |
The Message Scheduler for delayed (or scheduled) message delivery
|
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.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.shiro.authz | |
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.kahadb | |
org.apache.activemq.store.memory |
VM based implementation of message persistence
|
org.apache.activemq.util |
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 |
EmptyBroker.send(ProducerBrokerExchange producerExchange,
Message message) |
void |
TransactionBroker.send(ProducerBrokerExchange producerExchange,
Message message) |
void |
BrokerFilter.send(ProducerBrokerExchange producerExchange,
Message messageSend) |
void |
UserIDBroker.send(ProducerBrokerExchange producerExchange,
Message messageSend) |
void |
ErrorBroker.send(ProducerBrokerExchange producerExchange,
Message message) |
void |
BrokerBroadcaster.send(ProducerBrokerExchange producerExchange,
Message messageSend) |
void |
CompositeDestinationBroker.send(ProducerBrokerExchange producerExchange,
Message message) |
Modifier and Type | Method and Description |
---|---|
void |
MessageInterceptorRegistry.injectMessage(ProducerBrokerExchange producerExchange,
Message messageSend)
Re-inject into the Broker chain
|
void |
MessageInterceptor.intercept(ProducerBrokerExchange producerExchange,
Message message) |
Modifier and Type | Method and Description |
---|---|
protected 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[] |
Destination.browse() |
Message[] |
Queue.browse() |
Message[] |
Topic.browse() |
Message[] |
DestinationFilter.browse() |
Message |
NullMessageReference.getMessage() |
Message |
IndirectMessageReference.getMessage() |
Message |
MessageReference.getMessage() |
Message |
NullMessageReference.getMessageHardRef() |
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) |
void |
Destination.duplicateFromStore(Message message,
Subscription subscription) |
void |
BaseDestination.duplicateFromStore(Message message,
Subscription durableSub) |
void |
DestinationFilter.duplicateFromStore(Message message,
Subscription subscription) |
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 |
Region.send(ProducerBrokerExchange producerExchange,
Message message)
Send a message to the broker to using the specified destination.
|
void |
Destination.send(ProducerBrokerExchange producerExchange,
Message messageSend) |
void |
RegionBroker.send(ProducerBrokerExchange producerExchange,
Message message) |
void |
Queue.send(ProducerBrokerExchange producerExchange,
Message message) |
void |
Topic.send(ProducerBrokerExchange producerExchange,
Message message) |
void |
AbstractRegion.send(ProducerBrokerExchange producerExchange,
Message messageSend) |
void |
DestinationFilter.send(ProducerBrokerExchange context,
Message messageSend) |
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) |
protected void |
Queue.doBrowseList(List<Message> browseList,
int max,
PendingList list,
ReentrantReadWriteLock lock,
ConnectionContext connectionContext,
String name) |
Constructor and Description |
---|
IndirectMessageReference(Message message) |
PendingMarshalUsageTracker(Message message) |
Modifier and Type | Method and Description |
---|---|
protected Message |
FilePendingMessageCursor.getMessage(ByteSequence bs) |
Modifier and Type | Method and Description |
---|---|
protected boolean |
AbstractStoreCursor.duplicateFromStoreExcepted(Message message) |
protected ByteSequence |
FilePendingMessageCursor.getByteSequence(Message message) |
static boolean |
AbstractStoreCursor.gotToTheStore(Message message) |
boolean |
AbstractStoreCursor.recoverMessage(Message message) |
boolean |
AbstractStoreCursor.recoverMessage(Message message,
boolean cached) |
Modifier and Type | Method and Description |
---|---|
Message[] |
SubscriptionRecoveryPolicy.browse(ActiveMQDestination dest) |
Message[] |
QueryBasedSubscriptionRecoveryPolicy.browse(ActiveMQDestination dest) |
Message[] |
RetainedMessageSubscriptionRecoveryPolicy.browse(ActiveMQDestination destination) |
Message[] |
NoSubscriptionRecoveryPolicy.browse(ActiveMQDestination dest) |
Message[] |
FixedCountSubscriptionRecoveryPolicy.browse(ActiveMQDestination destination) |
Message[] |
LastImageSubscriptionRecoveryPolicy.browse(ActiveMQDestination destination) |
Message[] |
FixedSizedSubscriptionRecoveryPolicy.browse(ActiveMQDestination destination) |
Message[] |
TimedSubscriptionRecoveryPolicy.browse(ActiveMQDestination destination) |
Modifier and Type | Method and Description |
---|---|
protected ActiveMQDestination |
IndividualDeadLetterStrategy.createDestination(Message message,
String prefix,
String suffix,
boolean useQueue,
Subscription subscription) |
ActiveMQDestination |
DeadLetterStrategy.getDeadLetterQueueFor(Message message,
Subscription subscription)
Returns the dead letter queue for the given message and subscription.
|
ActiveMQDestination |
IndividualDeadLetterStrategy.getDeadLetterQueueFor(Message message,
Subscription subscription) |
ActiveMQDestination |
SharedDeadLetterStrategy.getDeadLetterQueueFor(Message message,
Subscription subscription) |
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 |
AbstractDeadLetterStrategy.isSendToDeadLetterQueue(Message message) |
boolean |
DiscardingDeadLetterStrategy.isSendToDeadLetterQueue(Message message) |
void |
DeadLetterStrategy.rollback(Message message)
Allows for a Message that was already processed by a DLQ to be rolled back in case
of a move or a retry of that message, otherwise the Message would be considered a
duplicate if this strategy is doing Message Auditing.
|
void |
AbstractDeadLetterStrategy.rollback(Message message) |
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 |
VirtualTopicInterceptor.send(ProducerBrokerExchange context,
Message message) |
void |
CompositeDestinationFilter.send(ProducerBrokerExchange context,
Message message) |
protected void |
VirtualTopicInterceptor.send(ProducerBrokerExchange context,
Message message,
ActiveMQDestination destination) |
protected boolean |
SelectorAwareVirtualTopicInterceptor.shouldDispatch(Broker broker,
Message message,
Destination dest)
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
|
protected boolean |
VirtualTopicInterceptor.shouldDispatch(Broker broker,
Message message,
Destination dest) |
Modifier and Type | Method and Description |
---|---|
void |
SchedulerBroker.send(ProducerBrokerExchange producerExchange,
Message messageSend) |
Modifier and Type | Method and Description |
---|---|
void |
TimeStampingBrokerPlugin.send(ProducerBrokerExchange producerExchange,
Message message) |
void |
UDPTraceBrokerPlugin.send(ProducerBrokerExchange producerExchange,
Message messageSend) |
void |
DestinationPathSeparatorBroker.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 |
---|---|
abstract Message |
Message.copy() |
Message |
ActiveMQMessage.copy() |
Message |
ActiveMQBlobMessage.copy() |
Message |
ActiveMQStreamMessage.copy() |
Message |
ActiveMQBytesMessage.copy() |
Message |
ActiveMQMapMessage.copy() |
Message |
ActiveMQTextMessage.copy() |
Message |
ActiveMQObjectMessage.copy() |
Message |
Message.getMessage() |
Message |
MessageDispatch.getMessage() |
Message |
Message.getMessageHardRef() |
Modifier and Type | Method and Description |
---|---|
protected void |
Message.copy(Message copy) |
static boolean |
NetworkBridgeFilter.isAdvisoryInterpretedByNetworkBridge(Message message) |
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 |
MessageEvaluationContext.getMessage() |
Message |
NonCachedMessageEvaluationContext.getMessage() |
Modifier and Type | Method and Description |
---|---|
boolean |
JAXPXPathEvaluator.evaluate(Message message) |
boolean |
XalanXPathEvaluator.evaluate(Message message) |
Object |
PropertyExpression.evaluate(Message message) |
boolean |
XPathExpression.XPathEvaluator.evaluate(Message message) |
static String[] |
DestinationPath.getDestinationPaths(Message message) |
Modifier and Type | Method and Description |
---|---|
Message[] |
SimpleMessageList.browse(ActiveMQDestination destination) |
Message[] |
MessageList.browse(ActiveMQDestination destination) |
Message[] |
DestinationBasedMessageList.browse(ActiveMQDestination destination) |
Modifier and Type | Method and Description |
---|---|
protected Message |
DemandForwardingBridgeSupport.configureMessage(MessageDispatch md) |
Modifier and Type | Method and Description |
---|---|
protected boolean |
DemandForwardingBridgeSupport.canDuplexDispatch(Message message) |
void |
MBeanBridgeDestination.onInboundMessage(Message message) |
void |
NetworkBridgeListener.onInboundMessage(NetworkBridge bridge,
Message message)
Called for when a message arrives over the network
|
void |
MBeanNetworkListener.onInboundMessage(NetworkBridge bridge,
Message message) |
void |
MBeanBridgeDestination.onOutboundMessage(Message message) |
void |
NetworkBridgeListener.onOutboundMessage(NetworkBridge bridge,
Message message)
Called when message forwarded over the network
|
void |
MBeanNetworkListener.onOutboundMessage(NetworkBridge bridge,
Message message) |
protected void |
DemandForwardingBridgeSupport.serviceInboundMessage(Message message) |
protected void |
DemandForwardingBridgeSupport.serviceOutbound(Message message) |
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 |
---|---|
void |
AuthorizationFilter.send(ProducerBrokerExchange exchange,
Message message) |
Modifier and Type | Method and Description |
---|---|
Response |
CommandVisitor.processMessage(Message send) |
Response |
ConnectionStateTracker.processMessage(Message send) |
Response |
CommandVisitorAdapter.processMessage(Message send) |
Modifier and Type | Field and Description |
---|---|
Message |
IndexListener.MessageContext.message |
Modifier and Type | Method and Description |
---|---|
Message |
MessageStore.getMessage(MessageId identity)
Looks up a message using either the String messageID or the
messageNumber.
|
Message |
ProxyTopicMessageStore.getMessage(MessageId identity) |
Message |
ProxyMessageStore.getMessage(MessageId identity) |
Modifier and Type | Method and Description |
---|---|
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) |
void |
MessageStore.addMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint)
Adds a message to the message store
|
void |
AbstractMessageStore.addMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint) |
void |
ProxyTopicMessageStore.addMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint) |
void |
ProxyMessageStore.addMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint) |
ListenableFuture<Object> |
MessageStore.asyncAddQueueMessage(ConnectionContext context,
Message message)
Adds a message to the message store
|
ListenableFuture<Object> |
AbstractMessageStore.asyncAddQueueMessage(ConnectionContext context,
Message message) |
ListenableFuture<Object> |
ProxyTopicMessageStore.asyncAddQueueMessage(ConnectionContext context,
Message message) |
ListenableFuture<Object> |
ProxyMessageStore.asyncAddQueueMessage(ConnectionContext context,
Message message) |
ListenableFuture<Object> |
MessageStore.asyncAddQueueMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint)
Adds a message to the message store
|
ListenableFuture<Object> |
AbstractMessageStore.asyncAddQueueMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint) |
ListenableFuture<Object> |
ProxyTopicMessageStore.asyncAddQueueMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint) |
ListenableFuture<Object> |
ProxyMessageStore.asyncAddQueueMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint) |
ListenableFuture<Object> |
MessageStore.asyncAddTopicMessage(ConnectionContext context,
Message message)
Adds a message to the message store
|
ListenableFuture<Object> |
AbstractMessageStore.asyncAddTopicMessage(ConnectionContext context,
Message message) |
ListenableFuture<Object> |
ProxyTopicMessageStore.asyncAddTopicMessage(ConnectionContext context,
Message message) |
ListenableFuture<Object> |
ProxyMessageStore.asyncAddTopicMessage(ConnectionContext context,
Message message) |
ListenableFuture<Object> |
MessageStore.asyncAddTopicMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint)
Adds a message to the message store
|
ListenableFuture<Object> |
AbstractMessageStore.asyncAddTopicMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint) |
ListenableFuture<Object> |
ProxyTopicMessageStore.asyncAddTopicMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint) |
ListenableFuture<Object> |
ProxyMessageStore.asyncAddTopicMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint) |
void |
TransactionRecoveryListener.recover(XATransactionId xid,
Message[] addedMessages,
MessageAck[] aks) |
boolean |
MessageRecoveryListener.recoverMessage(Message message) |
void |
MessageStore.updateMessage(Message message) |
void |
AbstractMessageStore.updateMessage(Message message) |
void |
ProxyTopicMessageStore.updateMessage(Message message) |
void |
ProxyMessageStore.updateMessage(Message message) |
Constructor and Description |
---|
MessageContext(ConnectionContext context,
Message message,
Runnable onCompletion) |
Modifier and Type | Method and Description |
---|---|
Message |
KahaDBStore.KahaDBMessageStore.getMessage(MessageId identity) |
Message |
TempKahaDBStore.KahaDBMessageStore.getMessage(MessageId identity) |
Message[] |
KahaDBTransactionStore.Tx.getMessages() |
Modifier and Type | Method and Description |
---|---|
void |
KahaDBStore.KahaDBMessageStore.addMessage(ConnectionContext context,
Message message) |
void |
TempKahaDBStore.KahaDBMessageStore.addMessage(ConnectionContext context,
Message message) |
ListenableFuture<Object> |
KahaDBStore.KahaDBMessageStore.asyncAddQueueMessage(ConnectionContext context,
Message message) |
void |
KahaDBStore.KahaDBMessageStore.updateMessage(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 |
MemoryTopicMessageStore.addMessage(ConnectionContext context,
Message message) |
void |
MemoryMessageStore.addMessage(ConnectionContext context,
Message message) |
protected static void |
MemoryMessageStore.decMessageStoreStatistics(MessageStoreStatistics stats,
Message message) |
protected static void |
MemoryMessageStore.incMessageStoreStatistics(MessageStoreStatistics stats,
Message message) |
void |
MemoryMessageStore.updateMessage(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–2017. All rights reserved.