Uses of Class
org.apache.activemq.command.Message
-
Packages that use Message 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 malarkyorg.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 storeorg.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 Destinationsorg.apache.activemq.broker.scheduler The Message Scheduler for delayed (or scheduled) message deliveryorg.apache.activemq.broker.util Some utility Broker Pluginsorg.apache.activemq.broker.view Broker Plugins for visualising the current systemorg.apache.activemq.command Command objects used via the Command Pattern to communicate among nodesorg.apache.activemq.filter Filter implementations for wildcards & JMS selectorsorg.apache.activemq.memory.list org.apache.activemq.network Support for federated networks of brokers.org.apache.activemq.partition 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 messagingorg.apache.activemq.store.jdbc Message persistence implemented using JDBCorg.apache.activemq.store.journal Message persistence using a high performance transaction log via the Journal interface.org.apache.activemq.store.kahadb org.apache.activemq.store.memory VM based implementation of message persistenceorg.apache.activemq.util -
-
Uses of Message in org.apache.activemq
Methods in org.apache.activemq with parameters of type Message Modifier and Type Method Description protected boolean
ActiveMQConnection. isDuplicate(ActiveMQDispatcher dispatcher, Message message)
protected void
ActiveMQConnection. rollbackDuplicate(ActiveMQDispatcher dispatcher, Message message)
-
Uses of Message in org.apache.activemq.broker
Methods in org.apache.activemq.broker with parameters of type Message Modifier and Type Method Description boolean
ProducerBrokerExchange. canDispatch(Message messageSend)
Enforce duplicate suppression using info from persistence adapterResponse
TransportConnection. processMessage(Message messageSend)
void
BrokerBroadcaster. send(ProducerBrokerExchange producerExchange, Message messageSend)
void
BrokerFilter. send(ProducerBrokerExchange producerExchange, Message messageSend)
void
CompositeDestinationBroker. send(ProducerBrokerExchange producerExchange, Message message)
void
EmptyBroker. send(ProducerBrokerExchange producerExchange, Message message)
void
ErrorBroker. send(ProducerBrokerExchange producerExchange, Message message)
void
TransactionBroker. send(ProducerBrokerExchange producerExchange, Message message)
void
UserIDBroker. send(ProducerBrokerExchange producerExchange, Message messageSend)
-
Uses of Message in org.apache.activemq.broker.inteceptor
Methods in org.apache.activemq.broker.inteceptor with parameters of type Message Modifier and Type Method Description void
MessageInterceptorRegistry. injectMessage(ProducerBrokerExchange producerExchange, Message messageSend)
Re-inject into the Broker chainvoid
MessageInterceptor. intercept(ProducerBrokerExchange producerExchange, Message message)
-
Uses of Message in org.apache.activemq.broker.jmx
Methods in org.apache.activemq.broker.jmx that return Message Modifier and Type Method Description protected Message[]
ManagedRegionBroker. getSubscriberMessages(SubscriptionView view)
Methods in org.apache.activemq.broker.jmx with parameters of type Message Modifier and Type Method Description void
ManagedRegionBroker. send(ProducerBrokerExchange exchange, Message message)
-
Uses of Message in org.apache.activemq.broker.region
Methods in org.apache.activemq.broker.region that return Message Modifier and Type Method Description Message[]
Destination. browse()
Message[]
DestinationFilter. browse()
Message[]
Queue. browse()
Message[]
Topic. browse()
Message
IndirectMessageReference. getMessage()
Message
MessageReference. getMessage()
Message
NullMessageReference. getMessage()
Message
IndirectMessageReference. getMessageHardRef()
Message
MessageReference. getMessageHardRef()
Message
NullMessageReference. getMessageHardRef()
Message
Topic. loadMessage(MessageId messageId)
Methods in org.apache.activemq.broker.region with parameters of type Message Modifier and Type Method 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
BaseDestination. duplicateFromStore(Message message, Subscription subscription)
void
Destination. duplicateFromStore(Message message, Subscription subscription)
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
AbstractRegion. send(ProducerBrokerExchange producerExchange, Message messageSend)
void
Destination. 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 wildcardvoid
Queue. send(ProducerBrokerExchange producerExchange, Message message)
void
Region. send(ProducerBrokerExchange producerExchange, Message message)
Send a message to the broker to using the specified destination.void
RegionBroker. send(ProducerBrokerExchange producerExchange, Message message)
void
Topic. send(ProducerBrokerExchange producerExchange, Message message)
Method parameters in org.apache.activemq.broker.region with type arguments of type Message Modifier and Type Method Description void
Queue. doBrowse(List<Message> browseList, int max)
void
Topic. doBrowse(List<Message> browseList, int max)
protected void
Queue. doBrowseList(List<Message> browseList, int max, PendingList list, ReentrantReadWriteLock lock, ConnectionContext connectionContext, String name)
Constructors in org.apache.activemq.broker.region with parameters of type Message Constructor Description IndirectMessageReference(Message message)
PendingMarshalUsageTracker(Message message)
-
Uses of Message in org.apache.activemq.broker.region.cursors
Methods in org.apache.activemq.broker.region.cursors that return Message Modifier and Type Method Description protected Message
FilePendingMessageCursor. getMessage(ByteSequence bs)
Methods in org.apache.activemq.broker.region.cursors with parameters of type Message Modifier and Type Method 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)
-
Uses of Message in org.apache.activemq.broker.region.policy
Methods in org.apache.activemq.broker.region.policy that return Message Modifier and Type Method Description Message[]
FixedCountSubscriptionRecoveryPolicy. browse(ActiveMQDestination destination)
Message[]
FixedSizedSubscriptionRecoveryPolicy. browse(ActiveMQDestination destination)
Message[]
LastImageSubscriptionRecoveryPolicy. browse(ActiveMQDestination destination)
Message[]
NoSubscriptionRecoveryPolicy. browse(ActiveMQDestination dest)
Message[]
QueryBasedSubscriptionRecoveryPolicy. browse(ActiveMQDestination dest)
Message[]
RetainedMessageSubscriptionRecoveryPolicy. browse(ActiveMQDestination destination)
Message[]
SubscriptionRecoveryPolicy. browse(ActiveMQDestination dest)
Message[]
TimedSubscriptionRecoveryPolicy. browse(ActiveMQDestination destination)
Methods in org.apache.activemq.broker.region.policy with parameters of type Message Modifier and Type Method 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
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 messagesboolean
DiscardingDeadLetterStrategy. isSendToDeadLetterQueue(Message message)
void
AbstractDeadLetterStrategy. rollback(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.boolean
MessageQuery. validateUpdate(Message message)
Returns true if the given update is valid and does not overlap with the initial message query. -
Uses of Message in org.apache.activemq.broker.region.virtual
Methods in org.apache.activemq.broker.region.virtual with parameters of type Message Modifier and Type Method Description void
CompositeDestinationFilter. send(ProducerBrokerExchange context, Message message)
void
VirtualTopicInterceptor. 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 destinationsprotected boolean
VirtualTopicInterceptor. shouldDispatch(Broker broker, Message message, Destination dest)
-
Uses of Message in org.apache.activemq.broker.scheduler
Methods in org.apache.activemq.broker.scheduler with parameters of type Message Modifier and Type Method Description void
SchedulerBroker. send(ProducerBrokerExchange producerExchange, Message messageSend)
-
Uses of Message in org.apache.activemq.broker.util
Methods in org.apache.activemq.broker.util with parameters of type Message Modifier and Type Method Description void
DestinationPathSeparatorBroker. send(ProducerBrokerExchange producerExchange, Message messageSend)
void
LoggingBrokerPlugin. send(ProducerBrokerExchange producerExchange, Message messageSend)
void
TimeStampingBrokerPlugin. send(ProducerBrokerExchange producerExchange, Message message)
void
UDPTraceBrokerPlugin. send(ProducerBrokerExchange producerExchange, Message messageSend)
-
Uses of Message in org.apache.activemq.broker.view
Methods in org.apache.activemq.broker.view with parameters of type Message Modifier and Type Method Description void
ConnectionDotFileInterceptor. send(ProducerBrokerExchange producerExchange, Message messageSend)
-
Uses of Message in org.apache.activemq.command
Subclasses of Message in org.apache.activemq.command Modifier and Type Class Description class
ActiveMQBlobMessage
An implementation ofBlobMessage
for out of band BLOB transferclass
ActiveMQBytesMessage
ABytesMessage
object is used to send a message containing a stream of uninterpreted bytes.class
ActiveMQMapMessage
AMapMessage
object is used to send a set of name-value pairs.class
ActiveMQMessage
class
ActiveMQObjectMessage
AnObjectMessage
object is used to send a message that contains a serializable object in the Java programming language ("Java object").class
ActiveMQStreamMessage
AStreamMessage
object is used to send a stream of primitive types in the Java programming language.class
ActiveMQTextMessage
Fields in org.apache.activemq.command declared as Message Modifier and Type Field Description protected Message
MessageDispatch. message
Methods in org.apache.activemq.command that return Message Modifier and Type Method Description Message
ActiveMQBlobMessage. copy()
Message
ActiveMQBytesMessage. copy()
Message
ActiveMQMapMessage. copy()
Message
ActiveMQMessage. copy()
Message
ActiveMQObjectMessage. copy()
Message
ActiveMQStreamMessage. copy()
Message
ActiveMQTextMessage. copy()
abstract Message
Message. copy()
Message
Message. getMessage()
Message
MessageDispatch. getMessage()
Message
Message. getMessageHardRef()
Methods in org.apache.activemq.command with parameters of type Message Modifier and Type Method 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)
Constructors in org.apache.activemq.command with parameters of type Message Constructor Description MessageAck(Message message, byte ackType, int messageCount)
-
Uses of Message in org.apache.activemq.filter
Fields in org.apache.activemq.filter declared as Message Modifier and Type Field Description protected Message
MessageEvaluationContext. message
Methods in org.apache.activemq.filter that return Message Modifier and Type Method Description Message
MessageEvaluationContext. getMessage()
Message
NonCachedMessageEvaluationContext. getMessage()
Methods in org.apache.activemq.filter with parameters of type Message Modifier and Type Method Description boolean
JAXPXPathEvaluator. evaluate(Message message)
Object
PropertyExpression. evaluate(Message message)
boolean
XalanXPathEvaluator. evaluate(Message message)
boolean
XPathExpression.XPathEvaluator. evaluate(Message message)
static String[]
DestinationPath. getDestinationPaths(Message message)
-
Uses of Message in org.apache.activemq.memory.list
Methods in org.apache.activemq.memory.list that return Message Modifier and Type Method Description Message[]
DestinationBasedMessageList. browse(ActiveMQDestination destination)
Message[]
MessageList. browse(ActiveMQDestination destination)
Message[]
SimpleMessageList. browse(ActiveMQDestination destination)
-
Uses of Message in org.apache.activemq.network
Methods in org.apache.activemq.network that return Message Modifier and Type Method Description protected Message
DemandForwardingBridgeSupport. configureMessage(MessageDispatch md)
Methods in org.apache.activemq.network with parameters of type Message Modifier and Type Method Description protected boolean
DemandForwardingBridgeSupport. canDuplexDispatch(Message message)
void
MBeanBridgeDestination. onInboundMessage(Message message)
void
MBeanNetworkListener. onInboundMessage(NetworkBridge bridge, Message message)
void
NetworkBridgeListener. onInboundMessage(NetworkBridge bridge, Message message)
Called for when a message arrives over the networkvoid
MBeanBridgeDestination. onOutboundMessage(Message message)
void
MBeanNetworkListener. onOutboundMessage(NetworkBridge bridge, Message message)
void
NetworkBridgeListener. onOutboundMessage(NetworkBridge bridge, Message message)
Called when message forwarded over the networkprotected void
DemandForwardingBridgeSupport. serviceInboundMessage(Message message)
protected void
DemandForwardingBridgeSupport. serviceOutbound(Message message)
-
Uses of Message in org.apache.activemq.partition
Methods in org.apache.activemq.partition with parameters of type Message Modifier and Type Method Description void
PartitionBroker. send(ProducerBrokerExchange producerExchange, Message messageSend)
-
Uses of Message in org.apache.activemq.plugin
Methods in org.apache.activemq.plugin with parameters of type Message Modifier and Type Method Description void
ForcePersistencyModeBroker. send(ProducerBrokerExchange producerExchange, Message messageSend)
Sets the persistence modevoid
StatisticsBroker. send(ProducerBrokerExchange producerExchange, Message messageSend)
Sets the persistence mode -
Uses of Message in org.apache.activemq.security
Methods in org.apache.activemq.security with parameters of type Message Modifier and Type Method Description boolean
MessageAuthorizationPolicy. isAllowedToConsume(ConnectionContext context, Message message)
Returns true if the given message is able to be dispatched to the connection performing any uservoid
AuthorizationBroker. send(ProducerBrokerExchange producerExchange, Message messageSend)
-
Uses of Message in org.apache.activemq.shiro.authz
Methods in org.apache.activemq.shiro.authz with parameters of type Message Modifier and Type Method Description void
AuthorizationFilter. send(ProducerBrokerExchange exchange, Message message)
-
Uses of Message in org.apache.activemq.state
Methods in org.apache.activemq.state with parameters of type Message Modifier and Type Method Description Response
CommandVisitor. processMessage(Message send)
Response
CommandVisitorAdapter. processMessage(Message send)
Response
ConnectionStateTracker. processMessage(Message send)
-
Uses of Message in org.apache.activemq.store
Fields in org.apache.activemq.store declared as Message Modifier and Type Field Description Message
IndexListener.MessageContext. message
Methods in org.apache.activemq.store that return Message Modifier and Type Method Description Message
MessageStore. getMessage(MessageId identity)
Looks up a message using either the String messageID or the messageNumber.Message
ProxyMessageStore. getMessage(MessageId identity)
Message
ProxyTopicMessageStore. getMessage(MessageId identity)
Methods in org.apache.activemq.store with parameters of type Message Modifier and Type Method Description void
AbstractMessageStore. addMessage(ConnectionContext context, Message message, boolean canOptimizeHint)
void
MessageStore. addMessage(ConnectionContext context, Message message)
Adds a message to the message storevoid
MessageStore. addMessage(ConnectionContext context, Message message, boolean canOptimizeHint)
Adds a message to the message storevoid
ProxyMessageStore. addMessage(ConnectionContext context, Message message)
void
ProxyMessageStore. addMessage(ConnectionContext context, Message message, boolean canOptimizeHint)
void
ProxyTopicMessageStore. addMessage(ConnectionContext context, Message message)
void
ProxyTopicMessageStore. addMessage(ConnectionContext context, Message message, boolean canOptimizeHint)
ListenableFuture<Object>
AbstractMessageStore. asyncAddQueueMessage(ConnectionContext context, Message message)
ListenableFuture<Object>
AbstractMessageStore. asyncAddQueueMessage(ConnectionContext context, Message message, boolean canOptimizeHint)
ListenableFuture<Object>
MessageStore. asyncAddQueueMessage(ConnectionContext context, Message message)
Adds a message to the message storeListenableFuture<Object>
MessageStore. asyncAddQueueMessage(ConnectionContext context, Message message, boolean canOptimizeHint)
Adds a message to the message storeListenableFuture<Object>
ProxyMessageStore. asyncAddQueueMessage(ConnectionContext context, Message message)
ListenableFuture<Object>
ProxyMessageStore. asyncAddQueueMessage(ConnectionContext context, Message message, boolean canOptimizeHint)
ListenableFuture<Object>
ProxyTopicMessageStore. asyncAddQueueMessage(ConnectionContext context, Message message)
ListenableFuture<Object>
ProxyTopicMessageStore. asyncAddQueueMessage(ConnectionContext context, Message message, boolean canOptimizeHint)
ListenableFuture<Object>
AbstractMessageStore. asyncAddTopicMessage(ConnectionContext context, Message message)
ListenableFuture<Object>
AbstractMessageStore. asyncAddTopicMessage(ConnectionContext context, Message message, boolean canOptimizeHint)
ListenableFuture<Object>
MessageStore. asyncAddTopicMessage(ConnectionContext context, Message message)
Adds a message to the message storeListenableFuture<Object>
MessageStore. asyncAddTopicMessage(ConnectionContext context, Message message, boolean canOptimizeHint)
Adds a message to the message storeListenableFuture<Object>
ProxyMessageStore. asyncAddTopicMessage(ConnectionContext context, Message message)
ListenableFuture<Object>
ProxyMessageStore. asyncAddTopicMessage(ConnectionContext context, Message message, boolean canOptimizeHint)
ListenableFuture<Object>
ProxyTopicMessageStore. asyncAddTopicMessage(ConnectionContext context, Message message)
ListenableFuture<Object>
ProxyTopicMessageStore. asyncAddTopicMessage(ConnectionContext context, Message message, boolean canOptimizeHint)
void
TransactionRecoveryListener. recover(XATransactionId xid, Message[] addedMessages, MessageAck[] aks)
boolean
MessageRecoveryListener. recoverMessage(Message message)
void
AbstractMessageStore. updateMessage(Message message)
void
MessageStore. updateMessage(Message message)
void
ProxyMessageStore. updateMessage(Message message)
void
ProxyTopicMessageStore. updateMessage(Message message)
Constructors in org.apache.activemq.store with parameters of type Message Constructor Description MessageContext(ConnectionContext context, Message message, Runnable onCompletion)
-
Uses of Message in org.apache.activemq.store.jdbc
Fields in org.apache.activemq.store.jdbc with type parameters of type Message Modifier and Type Field Description protected TreeMap<Long,Message>
JDBCMessageStore. rolledBackAcks
Methods in org.apache.activemq.store.jdbc that return Message Modifier and Type Method Description Message
JDBCMessageStore. getMessage(MessageId messageId)
Methods in org.apache.activemq.store.jdbc with parameters of type Message Modifier and Type Method Description void
JDBCMessageStore. addMessage(ConnectionContext context, Message message)
protected void
JDBCMessageStore. onAdd(Message message, long sequenceId, byte priority)
protected void
JDBCTopicMessageStore. onAdd(Message message, long sequenceId, byte priority)
void
JDBCMessageStore. trackRollbackAck(Message message)
void
JDBCMessageStore. updateMessage(Message message)
-
Uses of Message in org.apache.activemq.store.journal
Methods in org.apache.activemq.store.journal that return Message Modifier and Type Method Description Message
JournalMessageStore. getMessage(MessageId identity)
Message[]
JournalTransactionStore.Tx. getMessages()
Methods in org.apache.activemq.store.journal with parameters of type Message Modifier and Type Method 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)
-
Uses of Message in org.apache.activemq.store.kahadb
Methods in org.apache.activemq.store.kahadb that return Message Modifier and Type Method Description Message
KahaDBStore.KahaDBMessageStore. getMessage(MessageId identity)
Message
TempKahaDBStore.KahaDBMessageStore. getMessage(MessageId identity)
Message[]
KahaDBTransactionStore.Tx. getMessages()
Methods in org.apache.activemq.store.kahadb with parameters of type Message Modifier and Type Method 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)
-
Uses of Message in org.apache.activemq.store.memory
Fields in org.apache.activemq.store.memory with type parameters of type Message Modifier and Type Field Description protected Map<MessageId,Message>
MemoryMessageStore. messageTable
Methods in org.apache.activemq.store.memory that return Message Modifier and Type Method Description Message
MemoryMessageStore. getMessage(MessageId identity)
Message
MemoryTransactionStore.AddMessageCommand. getMessage()
Message[]
MemoryTransactionStore.Tx. getMessages()
Methods in org.apache.activemq.store.memory with parameters of type Message Modifier and Type Method Description void
MemoryMessageStore. addMessage(ConnectionContext context, Message message)
void
MemoryTopicMessageStore. 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 parameters in org.apache.activemq.store.memory with type arguments of type Message Constructor Description MemoryMessageStore(ActiveMQDestination destination, Map<MessageId,Message> messageTable)
MemoryTopicMessageStore(ActiveMQDestination destination, Map<MessageId,Message> messageTable, Map<SubscriptionKey,SubscriptionInfo> subscriberDatabase)
-
Uses of Message in org.apache.activemq.util
Methods in org.apache.activemq.util with parameters of type Message Modifier and Type Method 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)
-