|
||||||||||
PREV NEXT | FRAMES NO FRAMES |
Packages that use Message | |
---|---|
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 |
Uses of Message in org.apache.activemq |
---|
Methods in org.apache.activemq with parameters of type Message | |
---|---|
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 | |
---|---|
boolean |
ProducerBrokerExchange.canDispatch(Message messageSend)
Enforce duplicate suppression using info from persistence adapter |
Response |
TransportConnection.processMessage(Message messageSend)
|
void |
BrokerBroadcaster.send(ProducerBrokerExchange producerExchange,
Message messageSend)
|
void |
MutableBrokerFilter.send(ProducerBrokerExchange producerExchange,
Message messageSend)
|
void |
UserIDBroker.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 |
BrokerFilter.send(ProducerBrokerExchange producerExchange,
Message messageSend)
|
Uses of Message in org.apache.activemq.broker.ft |
---|
Methods in org.apache.activemq.broker.ft with parameters of type Message | |
---|---|
void |
MasterBroker.send(ProducerBrokerExchange producerExchange,
Message message)
|
protected void |
MasterBroker.sendToSlave(Message message)
|
Uses of Message in org.apache.activemq.broker.jmx |
---|
Methods in org.apache.activemq.broker.jmx that return types with arguments of type Message | |
---|---|
protected java.util.List<Message> |
ManagedRegionBroker.getSubscriberMessages(SubscriptionView view)
|
Methods in org.apache.activemq.broker.jmx with parameters of type Message | |
---|---|
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 | |
---|---|
Message[] |
DestinationFilter.browse()
|
Message[] |
Queue.browse()
|
Message[] |
Topic.browse()
|
Message[] |
Destination.browse()
|
Message |
IndirectMessageReference.getMessage()
|
Message |
MessageReference.getMessage()
|
Message |
IndirectMessageReference.getMessageHardRef()
|
Message |
MessageReference.getMessageHardRef()
|
Message |
Topic.loadMessage(MessageId messageId)
|
Methods in org.apache.activemq.broker.region with parameters of type Message | |
---|---|
protected MessageDispatch |
PrefetchSubscription.createMessageDispatch(MessageReference node,
Message message)
|
protected MessageDispatch |
DurableTopicSubscription.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 |
Region.send(ProducerBrokerExchange producerExchange,
Message message)
Send a message to the broker to using the specified destination. |
void |
DestinationFilter.send(ProducerBrokerExchange context,
Message messageSend)
|
void |
Queue.send(ProducerBrokerExchange producerExchange,
Message message)
|
void |
Topic.send(ProducerBrokerExchange producerExchange,
Message message)
|
void |
RegionBroker.send(ProducerBrokerExchange producerExchange,
Message message)
|
void |
AbstractRegion.send(ProducerBrokerExchange producerExchange,
Message messageSend)
|
void |
Destination.send(ProducerBrokerExchange producerExchange,
Message messageSend)
|
protected void |
DestinationFilter.send(ProducerBrokerExchange context,
Message message,
ActiveMQDestination destination)
Sends a message to the given destination which may be a wildcard |
Method parameters in org.apache.activemq.broker.region with type arguments of type Message | |
---|---|
void |
Queue.doBrowse(java.util.List<Message> browseList,
int max)
|
Constructors in org.apache.activemq.broker.region with parameters of type Message | |
---|---|
IndirectMessageReference(Message message)
|
Uses of Message in org.apache.activemq.broker.region.cursors |
---|
Methods in org.apache.activemq.broker.region.cursors that return Message | |
---|---|
protected Message |
FilePendingMessageCursor.getMessage(ByteSequence bs)
|
Methods in org.apache.activemq.broker.region.cursors with parameters of type Message | |
---|---|
protected ByteSequence |
FilePendingMessageCursor.getByteSequence(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 | |
---|---|
Message[] |
SubscriptionRecoveryPolicy.browse(ActiveMQDestination dest)
|
Message[] |
FixedSizedSubscriptionRecoveryPolicy.browse(ActiveMQDestination destination)
|
Message[] |
FixedCountSubscriptionRecoveryPolicy.browse(ActiveMQDestination destination)
|
Message[] |
NoSubscriptionRecoveryPolicy.browse(ActiveMQDestination dest)
|
Message[] |
TimedSubscriptionRecoveryPolicy.browse(ActiveMQDestination destination)
|
Message[] |
LastImageSubscriptionRecoveryPolicy.browse(ActiveMQDestination destination)
|
Message[] |
QueryBasedSubscriptionRecoveryPolicy.browse(ActiveMQDestination dest)
|
Methods in org.apache.activemq.broker.region.policy with parameters of type Message | |
---|---|
protected ActiveMQDestination |
IndividualDeadLetterStrategy.createDestination(Message message,
java.lang.String prefix,
boolean useQueue,
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)
|
ActiveMQDestination |
IndividualDeadLetterStrategy.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. |
Uses of Message in org.apache.activemq.broker.region.virtual |
---|
Methods in org.apache.activemq.broker.region.virtual with parameters of type Message | |
---|---|
void |
VirtualTopicInterceptor.send(ProducerBrokerExchange context,
Message message)
|
void |
CompositeDestinationFilter.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 |
Uses of Message in org.apache.activemq.broker.scheduler |
---|
Methods in org.apache.activemq.broker.scheduler with parameters of type Message | |
---|---|
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 | |
---|---|
void |
LoggingBrokerPlugin.send(ProducerBrokerExchange producerExchange,
Message messageSend)
|
void |
UDPTraceBrokerPlugin.send(ProducerBrokerExchange producerExchange,
Message messageSend)
|
void |
TimeStampingBrokerPlugin.send(ProducerBrokerExchange producerExchange,
Message message)
|
void |
DestinationPathSeparatorBroker.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 | |
---|---|
void |
ConnectionDotFileInterceptor.send(ProducerBrokerExchange producerExchange,
Message messageSend)
|
Uses of Message in org.apache.activemq.command |
---|
Subclasses of Message in org.apache.activemq.command | |
---|---|
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
|
Fields in org.apache.activemq.command declared as Message | |
---|---|
protected Message |
MessageDispatch.message
|
Methods in org.apache.activemq.command that return Message | |
---|---|
Message |
ActiveMQObjectMessage.copy()
|
Message |
ActiveMQMapMessage.copy()
|
Message |
ActiveMQBytesMessage.copy()
|
Message |
ActiveMQStreamMessage.copy()
|
abstract Message |
Message.copy()
|
Message |
ActiveMQMessage.copy()
|
Message |
ActiveMQBlobMessage.copy()
|
Message |
ActiveMQTextMessage.copy()
|
Message |
MessageDispatch.getMessage()
|
Message |
Message.getMessage()
|
Message |
Message.getMessageHardRef()
|
Methods in org.apache.activemq.command with parameters of type Message | |
---|---|
protected void |
Message.copy(Message copy)
|
protected boolean |
NetworkBridgeFilter.matchesForwardingFilter(Message message,
MessageEvaluationContext mec)
|
void |
MessageDispatch.setMessage(Message message)
|
Constructors in org.apache.activemq.command with parameters of type Message | |
---|---|
MessageAck(Message message,
byte ackType,
int messageCount)
|
Uses of Message in org.apache.activemq.filter |
---|
Fields in org.apache.activemq.filter declared as Message | |
---|---|
protected Message |
MessageEvaluationContext.message
|
Methods in org.apache.activemq.filter that return Message | |
---|---|
Message |
NonCachedMessageEvaluationContext.getMessage()
|
Message |
MessageEvaluationContext.getMessage()
|
Methods in org.apache.activemq.filter with parameters of type Message | |
---|---|
java.lang.Object |
PropertyExpression.evaluate(Message message)
|
boolean |
XPathExpression.XPathEvaluator.evaluate(Message message)
|
boolean |
XalanXPathEvaluator.evaluate(Message m)
|
static java.lang.String[] |
DestinationPath.getDestinationPaths(Message message)
|
Uses of Message in org.apache.activemq.kaha |
---|
Methods in org.apache.activemq.kaha that return Message | |
---|---|
Message |
MessageMarshaller.readPayload(java.io.DataInput dataIn)
Read the entry from the RawContainer |
Methods in org.apache.activemq.kaha with parameters of type Message | |
---|---|
void |
MessageMarshaller.writePayload(Message message,
java.io.DataOutput dataOut)
Write the payload of this entry to the RawContainer |
Uses of Message in org.apache.activemq.memory.list |
---|
Methods in org.apache.activemq.memory.list that return Message | |
---|---|
Message[] |
DestinationBasedMessageList.browse(ActiveMQDestination destination)
|
Message[] |
SimpleMessageList.browse(ActiveMQDestination destination)
|
Message[] |
MessageList.browse(ActiveMQDestination destination)
|
Uses of Message in org.apache.activemq.network |
---|
Methods in org.apache.activemq.network that return Message | |
---|---|
protected Message |
DemandForwardingBridgeSupport.configureMessage(MessageDispatch md)
|
Uses of Message in org.apache.activemq.plugin |
---|
Methods in org.apache.activemq.plugin with parameters of type Message | |
---|---|
void |
StatisticsBroker.send(ProducerBrokerExchange producerExchange,
Message messageSend)
Sets the persistence mode |
void |
ForcePersistencyModeBroker.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 | |
---|---|
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)
|
Uses of Message in org.apache.activemq.state |
---|
Methods in org.apache.activemq.state with parameters of type Message | |
---|---|
Response |
ConnectionStateTracker.processMessage(Message send)
|
Response |
CommandVisitorAdapter.processMessage(Message send)
|
Response |
CommandVisitor.processMessage(Message send)
|
Uses of Message in org.apache.activemq.store |
---|
Methods in org.apache.activemq.store that return Message | |
---|---|
Message |
ProxyTopicMessageStore.getMessage(MessageId identity)
|
Message |
ProxyMessageStore.getMessage(MessageId identity)
|
Message |
MessageStore.getMessage(MessageId identity)
Looks up a message using either the String messageID or the messageNumber. |
Methods in org.apache.activemq.store with parameters of type Message | |
---|---|
void |
ProxyTopicMessageStore.addMessage(ConnectionContext context,
Message message)
|
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,
boolean canOptimizeHint)
|
void |
AbstractMessageStore.addMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint)
|
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 |
java.util.concurrent.Future<java.lang.Object> |
ProxyTopicMessageStore.asyncAddQueueMessage(ConnectionContext context,
Message message)
|
java.util.concurrent.Future<java.lang.Object> |
AbstractMessageStore.asyncAddQueueMessage(ConnectionContext context,
Message message)
|
java.util.concurrent.Future<java.lang.Object> |
ProxyMessageStore.asyncAddQueueMessage(ConnectionContext context,
Message message)
|
java.util.concurrent.Future<java.lang.Object> |
MessageStore.asyncAddQueueMessage(ConnectionContext context,
Message message)
Adds a message to the message store |
java.util.concurrent.Future<java.lang.Object> |
ProxyTopicMessageStore.asyncAddQueueMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint)
|
java.util.concurrent.Future<java.lang.Object> |
AbstractMessageStore.asyncAddQueueMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint)
|
java.util.concurrent.Future<java.lang.Object> |
ProxyMessageStore.asyncAddQueueMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint)
|
java.util.concurrent.Future<java.lang.Object> |
MessageStore.asyncAddQueueMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint)
Adds a message to the message store |
java.util.concurrent.Future<java.lang.Object> |
ProxyTopicMessageStore.asyncAddTopicMessage(ConnectionContext context,
Message message)
|
java.util.concurrent.Future<java.lang.Object> |
AbstractMessageStore.asyncAddTopicMessage(ConnectionContext context,
Message message)
|
java.util.concurrent.Future<java.lang.Object> |
ProxyMessageStore.asyncAddTopicMessage(ConnectionContext context,
Message message)
|
java.util.concurrent.Future<java.lang.Object> |
MessageStore.asyncAddTopicMessage(ConnectionContext context,
Message message)
Adds a message to the message store |
java.util.concurrent.Future<java.lang.Object> |
ProxyTopicMessageStore.asyncAddTopicMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint)
|
java.util.concurrent.Future<java.lang.Object> |
AbstractMessageStore.asyncAddTopicMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint)
|
java.util.concurrent.Future<java.lang.Object> |
ProxyMessageStore.asyncAddTopicMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint)
|
java.util.concurrent.Future<java.lang.Object> |
MessageStore.asyncAddTopicMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint)
Adds a message to the message store |
void |
TransactionRecoveryListener.recover(XATransactionId xid,
Message[] addedMessages,
MessageAck[] aks)
|
boolean |
MessageRecoveryListener.recoverMessage(Message message)
|
Uses of Message in org.apache.activemq.store.amq |
---|
Methods in org.apache.activemq.store.amq that return Message | |
---|---|
Message |
AMQMessageStore.getMessage(MessageId identity)
|
Message[] |
AMQTx.getMessages()
|
Methods in org.apache.activemq.store.amq with parameters of type Message | |
---|---|
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)
|
Uses of Message in org.apache.activemq.store.jdbc |
---|
Methods in org.apache.activemq.store.jdbc that return Message | |
---|---|
Message |
JDBCMessageStore.getMessage(MessageId messageId)
|
Methods in org.apache.activemq.store.jdbc with parameters of type Message | |
---|---|
void |
JDBCMessageStore.addMessage(ConnectionContext context,
Message message)
|
Uses of Message in org.apache.activemq.store.journal |
---|
Methods in org.apache.activemq.store.journal that return Message | |
---|---|
Message |
JournalMessageStore.getMessage(MessageId identity)
|
Message[] |
JournalTransactionStore.Tx.getMessages()
|
Methods in org.apache.activemq.store.journal with parameters of type Message | |
---|---|
void |
JournalTransactionStore.Tx.add(JournalMessageStore store,
Message msg)
|
void |
JournalTopicMessageStore.addMessage(ConnectionContext context,
Message message)
|
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 |
JournalMessageStore.replayAddMessage(ConnectionContext context,
Message message)
|
Uses of Message in org.apache.activemq.store.kahadaptor |
---|
Fields in org.apache.activemq.store.kahadaptor with type parameters of type Message | |
---|---|
protected MapContainer<MessageId,Message> |
KahaMessageStore.messageContainer
|
Methods in org.apache.activemq.store.kahadaptor that return Message | |
---|---|
Message |
KahaTopicReferenceStore.getMessage(MessageId identity)
|
Message |
KahaReferenceStore.getMessage(MessageId identity)
|
Message |
KahaMessageStore.getMessage(MessageId identity)
|
Methods in org.apache.activemq.store.kahadaptor that return types with arguments of type Message | |
---|---|
protected MapContainer<MessageId,Message> |
KahaPersistenceAdapter.getMapContainer(java.lang.Object id,
java.lang.String containerName)
|
Methods in org.apache.activemq.store.kahadaptor with parameters of type Message | |
---|---|
void |
KahaTopicReferenceStore.addMessage(ConnectionContext context,
Message message)
|
void |
KahaReferenceStore.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 parameters in org.apache.activemq.store.kahadaptor with type arguments of type Message | |
---|---|
KahaMessageStore(MapContainer<MessageId,Message> container,
ActiveMQDestination destination)
|
|
KahaTopicMessageStore(Store store,
MapContainer<MessageId,Message> messageContainer,
ListContainer<TopicSubAck> ackContainer,
MapContainer<java.lang.String,SubscriptionInfo> subsContainer,
ActiveMQDestination destination)
|
Uses of Message in org.apache.activemq.store.kahadb |
---|
Methods in org.apache.activemq.store.kahadb that return Message | |
---|---|
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 | |
---|---|
void |
KahaDBStore.KahaDBMessageStore.addMessage(ConnectionContext context,
Message message)
|
void |
TempKahaDBStore.KahaDBMessageStore.addMessage(ConnectionContext context,
Message message)
|
java.util.concurrent.Future<java.lang.Object> |
KahaDBStore.KahaDBMessageStore.asyncAddQueueMessage(ConnectionContext context,
Message message)
|
Uses of Message in org.apache.activemq.store.memory |
---|
Fields in org.apache.activemq.store.memory with type parameters of type Message | |
---|---|
protected java.util.Map<MessageId,Message> |
MemoryMessageStore.messageTable
|
Methods in org.apache.activemq.store.memory that return Message | |
---|---|
Message |
MemoryTransactionStore.AddMessageCommand.getMessage()
|
Message |
MemoryMessageStore.getMessage(MessageId identity)
|
Message[] |
MemoryTransactionStore.Tx.getMessages()
|
Methods in org.apache.activemq.store.memory with parameters of type Message | |
---|---|
void |
MemoryTopicMessageStore.addMessage(ConnectionContext context,
Message message)
|
void |
MemoryMessageStore.addMessage(ConnectionContext context,
Message message)
|
Constructor parameters in org.apache.activemq.store.memory with type arguments of type Message | |
---|---|
MemoryMessageStore(ActiveMQDestination destination,
java.util.Map<MessageId,Message> messageTable)
|
|
MemoryTopicMessageStore(ActiveMQDestination destination,
java.util.Map<MessageId,Message> messageTable,
java.util.Map<SubscriptionKey,SubscriptionInfo> subscriberDatabase)
|
Uses of Message in org.apache.activemq.util |
---|
Methods in org.apache.activemq.util with parameters of type Message | |
---|---|
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)
|
|
||||||||||
PREV NEXT | FRAMES NO FRAMES |