Uses of Interface
org.apache.activemq.broker.region.MessageReference
-
Packages that use MessageReference Package Description org.apache.activemq The core JMS client API implementation classes.org.apache.activemq.advisory Support for JMS Advisory messages as well as some helper listeners to listen to the clients, producers and consumers available.org.apache.activemq.broker The core classes for the ActiveMQ Message Broker and its 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.util Some utility Broker Pluginsorg.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.buffer org.apache.activemq.memory.list org.apache.activemq.plugin -
-
Uses of MessageReference in org.apache.activemq
Methods in org.apache.activemq with parameters of type MessageReference Modifier and Type Method Description boolean
ActiveMQMessageAuditNoSync. isDuplicate(MessageReference message)
Checks if this message has been seen beforeboolean
ActiveMQMessageAuditNoSync. isInOrder(MessageReference message)
Check the MessageId is in ordervoid
ActiveMQMessageAuditNoSync. rollback(MessageReference message)
mark this message as being received -
Uses of MessageReference in org.apache.activemq.advisory
Methods in org.apache.activemq.advisory with parameters of type MessageReference Modifier and Type Method Description void
AdvisoryBroker. messageConsumed(ConnectionContext context, MessageReference messageReference)
void
AdvisoryBroker. messageDelivered(ConnectionContext context, MessageReference messageReference)
void
AdvisoryBroker. messageDiscarded(ConnectionContext context, Subscription sub, MessageReference messageReference)
void
AdvisoryBroker. messageExpired(ConnectionContext context, MessageReference messageReference, Subscription subscription)
boolean
AdvisoryBroker. sendToDeadLetterQueue(ConnectionContext context, MessageReference messageReference, Subscription subscription, Throwable poisonCause)
-
Uses of MessageReference in org.apache.activemq.broker
Methods in org.apache.activemq.broker with parameters of type MessageReference Modifier and Type Method Description boolean
ConnectionContext. isAllowedToConsume(MessageReference n)
boolean
Broker. isExpired(MessageReference messageReference)
Determine if a message has expired -allows default behaviour to be overriden - as the timestamp set by the producer can be out of sync with the brokerboolean
BrokerFilter. isExpired(MessageReference messageReference)
boolean
EmptyBroker. isExpired(MessageReference messageReference)
boolean
ErrorBroker. isExpired(MessageReference messageReference)
void
Broker. messageConsumed(ConnectionContext context, MessageReference messageReference)
called when message is consumedvoid
BrokerFilter. messageConsumed(ConnectionContext context, MessageReference messageReference)
void
EmptyBroker. messageConsumed(ConnectionContext context, MessageReference messageReference)
void
ErrorBroker. messageConsumed(ConnectionContext context, MessageReference messageReference)
void
Broker. messageDelivered(ConnectionContext context, MessageReference messageReference)
Called when message is delivered to the brokervoid
BrokerFilter. messageDelivered(ConnectionContext context, MessageReference messageReference)
void
EmptyBroker. messageDelivered(ConnectionContext context, MessageReference messageReference)
void
ErrorBroker. messageDelivered(ConnectionContext context, MessageReference messageReference)
void
Broker. messageDiscarded(ConnectionContext context, Subscription sub, MessageReference messageReference)
Called when a message is discarded - e.g.void
BrokerFilter. messageDiscarded(ConnectionContext context, Subscription sub, MessageReference messageReference)
void
EmptyBroker. messageDiscarded(ConnectionContext context, Subscription sub, MessageReference messageReference)
void
ErrorBroker. messageDiscarded(ConnectionContext context, Subscription sub, MessageReference messageReference)
void
Broker. messageExpired(ConnectionContext context, MessageReference messageReference, Subscription subscription)
A Message has Expiredvoid
BrokerFilter. messageExpired(ConnectionContext context, MessageReference message, Subscription subscription)
void
EmptyBroker. messageExpired(ConnectionContext context, MessageReference message, Subscription subscription)
void
ErrorBroker. messageExpired(ConnectionContext context, MessageReference message, Subscription subscription)
boolean
Broker. sendToDeadLetterQueue(ConnectionContext context, MessageReference messageReference, Subscription subscription, Throwable poisonCause)
A message needs to go the a DLQboolean
BrokerFilter. sendToDeadLetterQueue(ConnectionContext context, MessageReference messageReference, Subscription subscription, Throwable poisonCause)
boolean
EmptyBroker. sendToDeadLetterQueue(ConnectionContext context, MessageReference messageReference, Subscription subscription, Throwable poisonCause)
boolean
ErrorBroker. sendToDeadLetterQueue(ConnectionContext context, MessageReference messageReference, Subscription subscription, Throwable poisonCause)
-
Uses of MessageReference in org.apache.activemq.broker.region
Subinterfaces of MessageReference in org.apache.activemq.broker.region Modifier and Type Interface Description interface
QueueMessageReference
Queue specific MessageReference.Classes in org.apache.activemq.broker.region that implement MessageReference Modifier and Type Class Description class
IndirectMessageReference
Keeps track of a message that is flowing through the Broker.class
NullMessageReference
Used by theQueueMessageReference.NULL_MESSAGE
Fields in org.apache.activemq.broker.region with type parameters of type MessageReference Modifier and Type Field Description protected List<MessageReference>
PrefetchSubscription. dispatched
Methods in org.apache.activemq.broker.region that return types with arguments of type MessageReference Modifier and Type Method Description List<MessageReference>
AbstractSubscription. remove(ConnectionContext context, Destination destination)
List<MessageReference>
PrefetchSubscription. remove(ConnectionContext context, Destination destination)
List<MessageReference>
PrefetchSubscription. remove(ConnectionContext context, Destination destination, List<MessageReference> dispatched)
List<MessageReference>
QueueBrowserSubscription. remove(ConnectionContext context, Destination destination)
List<MessageReference>
Subscription. remove(ConnectionContext context, Destination destination)
The subscription will be no longer be receiving messages from the destination.Methods in org.apache.activemq.broker.region with parameters of type MessageReference Modifier and Type Method Description void
Destination. acknowledge(ConnectionContext context, Subscription sub, MessageAck ack, MessageReference node)
void
DestinationFilter. acknowledge(ConnectionContext context, Subscription sub, MessageAck ack, MessageReference node)
protected void
DurableTopicSubscription. acknowledge(ConnectionContext context, MessageAck ack, MessageReference node)
protected abstract void
PrefetchSubscription. acknowledge(ConnectionContext context, MessageAck ack, MessageReference node)
Used during acknowledgment to remove the message.void
Queue. acknowledge(ConnectionContext context, Subscription sub, MessageAck ack, MessageReference node)
protected void
QueueBrowserSubscription. acknowledge(ConnectionContext context, MessageAck ack, MessageReference n)
Since we are a browser we don't really remove the message from the queue.protected void
QueueSubscription. acknowledge(ConnectionContext context, MessageAck ack, MessageReference n)
In the queue case, mark the node as dropped and then a gc cycle will remove it from the queue.void
Topic. acknowledge(ConnectionContext context, Subscription sub, MessageAck ack, MessageReference node)
void
DurableTopicSubscription. add(MessageReference node)
void
PrefetchSubscription. add(MessageReference node)
void
Subscription. add(MessageReference node)
Used to add messages that match the subscription.void
TopicSubscription. add(MessageReference node)
boolean
AbstractSubscription. addRecoveredMessage(ConnectionContext context, MessageReference message)
boolean
SubscriptionRecovery. addRecoveredMessage(ConnectionContext context, MessageReference message)
Add a message to the SubscriptionRecoveryprotected void
Queue. assignGroup(Subscription subs, MessageGroupMap messageGroupOwners, MessageReference n, String groupId)
protected boolean
DurableTopicSubscription. canDispatch(MessageReference node)
protected abstract boolean
PrefetchSubscription. canDispatch(MessageReference node)
Use when a matched message is about to be dispatched to the client.protected boolean
QueueBrowserSubscription. canDispatch(MessageReference node)
protected boolean
QueueSubscription. canDispatch(MessageReference n)
boolean
QueueDispatchSelector. canSelect(Subscription subscription, MessageReference m)
protected MessageAck
BaseDestination. convertToNonRangedAck(MessageAck ack, MessageReference node)
protected MessageDispatch
DurableTopicSubscription. createMessageDispatch(MessageReference node, Message message)
protected MessageDispatch
PrefetchSubscription. createMessageDispatch(MessageReference node, Message message)
protected boolean
PrefetchSubscription. dispatch(MessageReference node)
protected void
AbstractSubscription. doAddRecoveredMessage(MessageReference message)
protected void
DurableTopicSubscription. doAddRecoveredMessage(MessageReference message)
boolean
MessageReferenceFilter. evaluate(ConnectionContext context, MessageReference messageReference)
protected boolean
DurableTopicSubscription. isDropped(MessageReference node)
protected abstract boolean
PrefetchSubscription. isDropped(MessageReference node)
protected boolean
QueueSubscription. isDropped(MessageReference node)
boolean
RegionBroker. isExpired(MessageReference messageReference)
boolean
Topic. lock(MessageReference node, LockOwner sub)
boolean
AbstractSubscription. matches(MessageReference node, MessageEvaluationContext context)
boolean
QueueBrowserSubscription. matches(MessageReference node, MessageEvaluationContext context)
boolean
Subscription. matches(MessageReference node, MessageEvaluationContext context)
Is the subscription interested in the message?void
BaseDestination. messageConsumed(ConnectionContext context, MessageReference messageReference)
called when message is consumedvoid
Destination. messageConsumed(ConnectionContext context, MessageReference messageReference)
called when message is consumedvoid
DestinationFilter. messageConsumed(ConnectionContext context, MessageReference messageReference)
void
BaseDestination. messageDelivered(ConnectionContext context, MessageReference messageReference)
Called when message is delivered to the brokervoid
Destination. messageDelivered(ConnectionContext context, MessageReference messageReference)
Called when message is delivered to the brokervoid
DestinationFilter. messageDelivered(ConnectionContext context, MessageReference messageReference)
void
BaseDestination. messageDiscarded(ConnectionContext context, Subscription sub, MessageReference messageReference)
Called when a message is discarded - e.g.void
Destination. messageDiscarded(ConnectionContext context, Subscription sub, MessageReference messageReference)
Called when a message is discarded - e.g.void
DestinationFilter. messageDiscarded(ConnectionContext context, Subscription sub, MessageReference messageReference)
void
Destination. messageExpired(ConnectionContext context, Subscription subs, MessageReference node)
Inform the Destination a message has expiredvoid
DestinationFilter. messageExpired(ConnectionContext context, PrefetchSubscription prefetchSubscription, MessageReference node)
void
DestinationFilter. messageExpired(ConnectionContext context, Subscription subs, MessageReference node)
void
Queue. messageExpired(ConnectionContext context, MessageReference reference)
void
Queue. messageExpired(ConnectionContext context, Subscription subs, MessageReference reference)
void
RegionBroker. messageExpired(ConnectionContext context, MessageReference node, Subscription subscription)
void
Topic. messageExpired(ConnectionContext context, Subscription subs, MessageReference reference)
protected void
PrefetchSubscription. onDispatch(MessageReference node, Message message)
void
DurableTopicSubscription. removePending(MessageReference node)
boolean
RegionBroker. sendToDeadLetterQueue(ConnectionContext context, MessageReference node, Subscription subscription, Throwable poisonCause)
protected void
PrefetchSubscription. sendToDLQ(ConnectionContext context, MessageReference node, Throwable poisonCause)
protected boolean
DurableTopicSubscription. trackedInPendingTransaction(MessageReference node)
protected boolean
PrefetchSubscription. trackedInPendingTransaction(MessageReference node)
void
AbstractSubscription. unmatched(MessageReference node)
void
DurableTopicSubscription. unmatched(MessageReference node)
store will have a pending ack for all durables, irrespective of the selector so we need to ack if node is un-matchedvoid
Subscription. unmatched(MessageReference node)
Method parameters in org.apache.activemq.broker.region with type arguments of type MessageReference Modifier and Type Method Description void
Topic. deactivate(ConnectionContext context, DurableTopicSubscription sub, List<MessageReference> dispatched)
List<MessageReference>
PrefetchSubscription. remove(ConnectionContext context, Destination destination, List<MessageReference> dispatched)
-
Uses of MessageReference in org.apache.activemq.broker.region.cursors
Fields in org.apache.activemq.broker.region.cursors declared as MessageReference Modifier and Type Field Description protected MessageReference
AbstractPendingMessageCursor. last
Methods in org.apache.activemq.broker.region.cursors that return MessageReference Modifier and Type Method Description MessageReference
OrderedPendingList. get(MessageId messageId)
MessageReference
PendingList. get(MessageId messageId)
MessageReference
PrioritizedPendingList. get(MessageId messageId)
MessageReference
QueueDispatchPendingList. get(MessageId messageId)
MessageReference
AbstractPendingMessageCursor. next()
MessageReference
AbstractStoreCursor. next()
MessageReference
FilePendingMessageCursor. next()
MessageReference
PendingMessageCursor. next()
MessageReference
StoreDurableSubscriberCursor. next()
MessageReference
StoreQueueCursor. next()
MessageReference
VMPendingMessageCursor. next()
Methods in org.apache.activemq.broker.region.cursors that return types with arguments of type MessageReference Modifier and Type Method Description static Collection<MessageReference>
OrderedPendingList. getValues(PendingList pendingList)
Iterator<MessageReference>
OrderedPendingList. iterator()
Iterator<MessageReference>
PendingList. iterator()
Returns an iterator over the pending Messages.Iterator<MessageReference>
PrioritizedPendingList. iterator()
Iterator<MessageReference>
QueueDispatchPendingList. iterator()
LinkedList<MessageReference>
AbstractPendingMessageCursor. pageInList(int maxItems)
Page in a restricted number of messagesLinkedList<MessageReference>
FilePendingMessageCursor. pageInList(int maxItems)
LinkedList<MessageReference>
PendingMessageCursor. pageInList(int maxItems)
Page in a restricted number of messages and increment the reference countLinkedList<MessageReference>
VMPendingMessageCursor. pageInList(int maxItems)
Page in a restricted number of messagesList<MessageReference>
AbstractPendingMessageCursor. remove(ConnectionContext context, Destination destination)
List<MessageReference>
PendingMessageCursor. remove(ConnectionContext context, Destination destination)
remove a destinationList<MessageReference>
StoreDurableSubscriberCursor. remove(ConnectionContext context, Destination destination)
remove a destinationList<MessageReference>
VMPendingMessageCursor. remove(ConnectionContext context, Destination destination)
Collection<MessageReference>
OrderedPendingList. values()
Collection<MessageReference>
PendingList. values()
Returns a new Collection that contains all the MessageReferences currently held in this PendingList.Collection<MessageReference>
PrioritizedPendingList. values()
Collection<MessageReference>
QueueDispatchPendingList. values()
Methods in org.apache.activemq.broker.region.cursors with parameters of type MessageReference Modifier and Type Method Description void
AbstractPendingMessageCursor. addMessageFirst(MessageReference node)
void
AbstractStoreCursor. addMessageFirst(MessageReference node)
void
FilePendingMessageCursor. addMessageFirst(MessageReference node)
add message to await dispatchPendingNode
OrderedPendingList. addMessageFirst(MessageReference message)
PendingNode
PendingList. addMessageFirst(MessageReference message)
Adds the given message to the head of the list.void
PendingMessageCursor. addMessageFirst(MessageReference node)
add message to await dispatchPendingNode
PrioritizedPendingList. addMessageFirst(MessageReference message)
PendingNode
QueueDispatchPendingList. addMessageFirst(MessageReference message)
Messages added are added directly to the pagedInPendingDispatch set of messages.void
StoreDurableSubscriberCursor. addMessageFirst(MessageReference node)
void
StoreQueueCursor. addMessageFirst(MessageReference node)
void
VMPendingMessageCursor. addMessageFirst(MessageReference node)
add message to await dispatchboolean
AbstractPendingMessageCursor. addMessageLast(MessageReference node)
PendingNode
OrderedPendingList. addMessageLast(MessageReference message)
PendingNode
PendingList. addMessageLast(MessageReference message)
Adds the given message to the tail of the list.boolean
PendingMessageCursor. addMessageLast(MessageReference node)
add message to await dispatchPendingNode
PrioritizedPendingList. addMessageLast(MessageReference message)
PendingNode
QueueDispatchPendingList. addMessageLast(MessageReference message)
Messages added are added directly to the pagedInPendingDispatch set of messages.void
AbstractPendingMessageCursor. addRecoveredMessage(MessageReference node)
void
PendingMessageCursor. addRecoveredMessage(MessageReference node)
Add a message recovered from a retroactive policyvoid
StoreDurableSubscriberCursor. addRecoveredMessage(MessageReference node)
void
PendingMessageHelper. addToMap(MessageReference message, PendingNode node)
boolean
OrderedPendingList. contains(MessageReference message)
boolean
PendingList. contains(MessageReference message)
Query the PendingList to determine if the given message is contained within.boolean
PrioritizedPendingList. contains(MessageReference message)
boolean
QueueDispatchPendingList. contains(MessageReference message)
protected OrderedPendingList
PrioritizedPendingList. getList(MessageReference msg)
protected int
PrioritizedPendingList. getPriority(MessageReference message)
void
AbstractPendingMessageCursor. remove(MessageReference node)
void
AbstractStoreCursor. remove(MessageReference node)
void
FilePendingMessageCursor. remove(MessageReference node)
PendingNode
OrderedPendingList. remove(MessageReference message)
PendingNode
PendingList. remove(MessageReference message)
Removes the given MessageReference from the PendingList if it is contained within.void
PendingMessageCursor. remove(MessageReference node)
remove a nodePendingNode
PrioritizedPendingList. remove(MessageReference message)
PendingNode
QueueDispatchPendingList. remove(MessageReference message)
void
StoreDurableSubscriberCursor. remove(MessageReference node)
void
StoreQueueCursor. remove(MessageReference node)
void
VMPendingMessageCursor. remove(MessageReference node)
PendingNode
PendingMessageHelper. removeFromMap(MessageReference message)
boolean
AbstractPendingMessageCursor. tryAddMessageLast(MessageReference node, long maxWaitTime)
boolean
AbstractStoreCursor. tryAddMessageLast(MessageReference node, long wait)
boolean
FilePendingMessageCursor. tryAddMessageLast(MessageReference node, long maxWaitTime)
add message to await dispatchboolean
PendingMessageCursor. tryAddMessageLast(MessageReference node, long maxWaitTime)
add message to await dispatch - if it canboolean
StoreDurableSubscriberCursor. tryAddMessageLast(MessageReference node, long wait)
boolean
StoreQueueCursor. tryAddMessageLast(MessageReference node, long maxWait)
boolean
VMPendingMessageCursor. tryAddMessageLast(MessageReference node, long maxWait)
add message to await dispatchMethod parameters in org.apache.activemq.broker.region.cursors with type arguments of type MessageReference Modifier and Type Method Description void
QueueDispatchPendingList. addForRedelivery(List<MessageReference> list, boolean noConsumers)
void
OrderedPendingList. insertAtHead(List<MessageReference> list)
Constructors in org.apache.activemq.broker.region.cursors with parameters of type MessageReference Constructor Description PendingNode(OrderedPendingList list, MessageReference message)
-
Uses of MessageReference in org.apache.activemq.broker.region.policy
Methods in org.apache.activemq.broker.region.policy that return MessageReference Modifier and Type Method Description MessageReference[]
MessageEvictionStrategy. evictMessages(LinkedList messages)
Find the message reference in the given list with oldest messages at the front and newer messages at the endMessageReference[]
OldestMessageEvictionStrategy. evictMessages(LinkedList messages)
MessageReference[]
OldestMessageWithLowestPriorityEvictionStrategy. evictMessages(LinkedList messages)
MessageReference[]
UniquePropertyMessageEvictionStrategy. evictMessages(LinkedList messages)
Methods in org.apache.activemq.broker.region.policy with parameters of type MessageReference Modifier and Type Method Description boolean
FixedCountSubscriptionRecoveryPolicy. add(ConnectionContext context, MessageReference node)
boolean
FixedSizedSubscriptionRecoveryPolicy. add(ConnectionContext context, MessageReference message)
boolean
LastImageSubscriptionRecoveryPolicy. add(ConnectionContext context, MessageReference node)
boolean
NoSubscriptionRecoveryPolicy. add(ConnectionContext context, MessageReference node)
boolean
QueryBasedSubscriptionRecoveryPolicy. add(ConnectionContext context, MessageReference message)
boolean
RetainedMessageSubscriptionRecoveryPolicy. add(ConnectionContext context, MessageReference node)
boolean
SubscriptionRecoveryPolicy. add(ConnectionContext context, MessageReference message)
A message was sent to the destination.boolean
TimedSubscriptionRecoveryPolicy. add(ConnectionContext context, MessageReference message)
boolean
DispatchSelector. canDispatch(Subscription subscription, MessageReference node)
return true if a subscription can dispatch a message referenceboolean
SimpleDispatchSelector. canDispatch(Subscription subscription, MessageReference node)
boolean
ClientIdFilterDispatchPolicy. dispatch(MessageReference node, MessageEvaluationContext msgContext, List<Subscription> consumers)
boolean
DispatchPolicy. dispatch(MessageReference node, MessageEvaluationContext msgContext, List<Subscription> consumers)
Decides how to dispatch a selected message to a collection of consumers.boolean
PriorityDispatchPolicy. dispatch(MessageReference node, MessageEvaluationContext msgContext, List<Subscription> consumers)
boolean
PriorityNetworkDispatchPolicy. dispatch(MessageReference node, MessageEvaluationContext msgContext, List<Subscription> consumers)
boolean
RoundRobinDispatchPolicy. dispatch(MessageReference node, MessageEvaluationContext msgContext, List<Subscription> consumers)
boolean
SimpleDispatchPolicy. dispatch(MessageReference node, MessageEvaluationContext msgContext, List<Subscription> consumers)
boolean
StrictOrderDispatchPolicy. dispatch(MessageReference node, MessageEvaluationContext msgContext, List consumers)
-
Uses of MessageReference in org.apache.activemq.broker.util
Methods in org.apache.activemq.broker.util with parameters of type MessageReference Modifier and Type Method Description void
LoggingBrokerPlugin. messageConsumed(ConnectionContext context, MessageReference messageReference)
void
LoggingBrokerPlugin. messageDelivered(ConnectionContext context, MessageReference messageReference)
void
LoggingBrokerPlugin. messageDiscarded(ConnectionContext context, Subscription sub, MessageReference messageReference)
void
LoggingBrokerPlugin. messageExpired(ConnectionContext context, MessageReference message, Subscription subscription)
boolean
LoggingBrokerPlugin. sendToDeadLetterQueue(ConnectionContext context, MessageReference messageReference, Subscription subscription, Throwable poisonCause)
boolean
RedeliveryPlugin. sendToDeadLetterQueue(ConnectionContext context, MessageReference messageReference, Subscription subscription, Throwable poisonCause)
-
Uses of MessageReference in org.apache.activemq.command
Classes in org.apache.activemq.command that implement MessageReference 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
class
Message
Represents an ActiveMQ message -
Uses of MessageReference in org.apache.activemq.filter
Fields in org.apache.activemq.filter declared as MessageReference Modifier and Type Field Description protected MessageReference
MessageEvaluationContext. messageReference
Methods in org.apache.activemq.filter that return MessageReference Modifier and Type Method Description MessageReference
MessageEvaluationContext. getMessageReference()
Methods in org.apache.activemq.filter with parameters of type MessageReference Modifier and Type Method Description void
MessageEvaluationContext. setMessageReference(MessageReference messageReference)
void
NonCachedMessageEvaluationContext. setMessageReference(MessageReference messageReference)
-
Uses of MessageReference in org.apache.activemq.memory.buffer
Methods in org.apache.activemq.memory.buffer that return types with arguments of type MessageReference Modifier and Type Method Description List<MessageReference>
MessageQueue. getList()
Returns a copy of the listMethods in org.apache.activemq.memory.buffer with parameters of type MessageReference Modifier and Type Method Description void
MessageQueue. add(MessageReference messageRef)
Method parameters in org.apache.activemq.memory.buffer with type arguments of type MessageReference Modifier and Type Method Description void
MessageQueue. appendMessages(List<MessageReference> answer)
-
Uses of MessageReference in org.apache.activemq.memory.list
Methods in org.apache.activemq.memory.list that return types with arguments of type MessageReference Modifier and Type Method Description List<MessageReference>
SimpleMessageList. getList()
Returns a copy of the listList<MessageReference>
DestinationBasedMessageList. getMessages(Subscription sub)
List<MessageReference>
DestinationBasedMessageList. getMessages(ActiveMQDestination destination)
List<MessageReference>
SimpleMessageList. getMessages(ActiveMQDestination destination)
Methods in org.apache.activemq.memory.list with parameters of type MessageReference Modifier and Type Method Description void
DestinationBasedMessageList. add(MessageReference node)
void
MessageList. add(MessageReference node)
void
SimpleMessageList. add(MessageReference node)
-
Uses of MessageReference in org.apache.activemq.plugin
Methods in org.apache.activemq.plugin with parameters of type MessageReference Modifier and Type Method Description boolean
DiscardingDLQBroker. sendToDeadLetterQueue(ConnectionContext ctx, MessageReference msgRef, Subscription subscription, Throwable poisonCause)
-