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.activemqMethods in org.apache.activemq with parameters of type MessageReference Modifier and Type Method Description booleanActiveMQMessageAuditNoSync. isDuplicate(MessageReference message)Checks if this message has been seen beforebooleanActiveMQMessageAuditNoSync. isInOrder(MessageReference message)Check the MessageId is in ordervoidActiveMQMessageAuditNoSync. rollback(MessageReference message)mark this message as being received
- 
Uses of MessageReference in org.apache.activemq.advisoryMethods in org.apache.activemq.advisory with parameters of type MessageReference Modifier and Type Method Description voidAdvisoryBroker. messageConsumed(ConnectionContext context, MessageReference messageReference)voidAdvisoryBroker. messageDelivered(ConnectionContext context, MessageReference messageReference)voidAdvisoryBroker. messageDiscarded(ConnectionContext context, Subscription sub, MessageReference messageReference)voidAdvisoryBroker. messageExpired(ConnectionContext context, MessageReference messageReference, Subscription subscription)booleanAdvisoryBroker. sendToDeadLetterQueue(ConnectionContext context, MessageReference messageReference, Subscription subscription, Throwable poisonCause)
- 
Uses of MessageReference in org.apache.activemq.brokerMethods in org.apache.activemq.broker with parameters of type MessageReference Modifier and Type Method Description booleanConnectionContext. isAllowedToConsume(MessageReference n)booleanBroker. 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 brokerbooleanBrokerFilter. isExpired(MessageReference messageReference)booleanEmptyBroker. isExpired(MessageReference messageReference)booleanErrorBroker. isExpired(MessageReference messageReference)voidBroker. messageConsumed(ConnectionContext context, MessageReference messageReference)called when message is consumedvoidBrokerFilter. messageConsumed(ConnectionContext context, MessageReference messageReference)voidEmptyBroker. messageConsumed(ConnectionContext context, MessageReference messageReference)voidErrorBroker. messageConsumed(ConnectionContext context, MessageReference messageReference)voidBroker. messageDelivered(ConnectionContext context, MessageReference messageReference)Called when message is delivered to the brokervoidBrokerFilter. messageDelivered(ConnectionContext context, MessageReference messageReference)voidEmptyBroker. messageDelivered(ConnectionContext context, MessageReference messageReference)voidErrorBroker. messageDelivered(ConnectionContext context, MessageReference messageReference)voidBroker. messageDiscarded(ConnectionContext context, Subscription sub, MessageReference messageReference)Called when a message is discarded - e.g.voidBrokerFilter. messageDiscarded(ConnectionContext context, Subscription sub, MessageReference messageReference)voidEmptyBroker. messageDiscarded(ConnectionContext context, Subscription sub, MessageReference messageReference)voidErrorBroker. messageDiscarded(ConnectionContext context, Subscription sub, MessageReference messageReference)voidBroker. messageExpired(ConnectionContext context, MessageReference messageReference, Subscription subscription)A Message has ExpiredvoidBrokerFilter. messageExpired(ConnectionContext context, MessageReference message, Subscription subscription)voidEmptyBroker. messageExpired(ConnectionContext context, MessageReference message, Subscription subscription)voidErrorBroker. messageExpired(ConnectionContext context, MessageReference message, Subscription subscription)booleanBroker. sendToDeadLetterQueue(ConnectionContext context, MessageReference messageReference, Subscription subscription, Throwable poisonCause)A message needs to go the a DLQbooleanBrokerFilter. sendToDeadLetterQueue(ConnectionContext context, MessageReference messageReference, Subscription subscription, Throwable poisonCause)booleanEmptyBroker. sendToDeadLetterQueue(ConnectionContext context, MessageReference messageReference, Subscription subscription, Throwable poisonCause)booleanErrorBroker. sendToDeadLetterQueue(ConnectionContext context, MessageReference messageReference, Subscription subscription, Throwable poisonCause)
- 
Uses of MessageReference in org.apache.activemq.broker.regionSubinterfaces of MessageReference in org.apache.activemq.broker.region Modifier and Type Interface Description interfaceQueueMessageReferenceQueue specific MessageReference.Classes in org.apache.activemq.broker.region that implement MessageReference Modifier and Type Class Description classIndirectMessageReferenceKeeps track of a message that is flowing through the Broker.classNullMessageReferenceUsed by theQueueMessageReference.NULL_MESSAGEFields in org.apache.activemq.broker.region with type parameters of type MessageReference Modifier and Type Field Description protected List<MessageReference>PrefetchSubscription. dispatchedMethods 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 voidDestination. acknowledge(ConnectionContext context, Subscription sub, MessageAck ack, MessageReference node)voidDestinationFilter. acknowledge(ConnectionContext context, Subscription sub, MessageAck ack, MessageReference node)protected voidDurableTopicSubscription. acknowledge(ConnectionContext context, MessageAck ack, MessageReference node)protected abstract voidPrefetchSubscription. acknowledge(ConnectionContext context, MessageAck ack, MessageReference node)Used during acknowledgment to remove the message.voidQueue. acknowledge(ConnectionContext context, Subscription sub, MessageAck ack, MessageReference node)protected voidQueueBrowserSubscription. acknowledge(ConnectionContext context, MessageAck ack, MessageReference n)Since we are a browser we don't really remove the message from the queue.protected voidQueueSubscription. 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.voidTopic. acknowledge(ConnectionContext context, Subscription sub, MessageAck ack, MessageReference node)voidDurableTopicSubscription. add(MessageReference node)voidPrefetchSubscription. add(MessageReference node)voidSubscription. add(MessageReference node)Used to add messages that match the subscription.voidTopicSubscription. add(MessageReference node)booleanAbstractSubscription. addRecoveredMessage(ConnectionContext context, MessageReference message)booleanSubscriptionRecovery. addRecoveredMessage(ConnectionContext context, MessageReference message)Add a message to the SubscriptionRecoveryprotected voidQueue. assignGroup(Subscription subs, MessageGroupMap messageGroupOwners, MessageReference n, String groupId)protected booleanDurableTopicSubscription. canDispatch(MessageReference node)protected abstract booleanPrefetchSubscription. canDispatch(MessageReference node)Use when a matched message is about to be dispatched to the client.protected booleanQueueBrowserSubscription. canDispatch(MessageReference node)protected booleanQueueSubscription. canDispatch(MessageReference n)booleanQueueDispatchSelector. canSelect(Subscription subscription, MessageReference m)protected MessageAckBaseDestination. convertToNonRangedAck(MessageAck ack, MessageReference node)protected MessageDispatchDurableTopicSubscription. createMessageDispatch(MessageReference node, Message message)protected MessageDispatchPrefetchSubscription. createMessageDispatch(MessageReference node, Message message)protected booleanPrefetchSubscription. dispatch(MessageReference node)protected voidAbstractSubscription. doAddRecoveredMessage(MessageReference message)protected voidDurableTopicSubscription. doAddRecoveredMessage(MessageReference message)booleanMessageReferenceFilter. evaluate(ConnectionContext context, MessageReference messageReference)protected booleanDurableTopicSubscription. isDropped(MessageReference node)protected abstract booleanPrefetchSubscription. isDropped(MessageReference node)protected booleanQueueSubscription. isDropped(MessageReference node)booleanRegionBroker. isExpired(MessageReference messageReference)booleanTopic. lock(MessageReference node, LockOwner sub)booleanAbstractSubscription. matches(MessageReference node, MessageEvaluationContext context)booleanQueueBrowserSubscription. matches(MessageReference node, MessageEvaluationContext context)booleanSubscription. matches(MessageReference node, MessageEvaluationContext context)Is the subscription interested in the message?voidBaseDestination. messageConsumed(ConnectionContext context, MessageReference messageReference)called when message is consumedvoidDestination. messageConsumed(ConnectionContext context, MessageReference messageReference)called when message is consumedvoidDestinationFilter. messageConsumed(ConnectionContext context, MessageReference messageReference)voidBaseDestination. messageDelivered(ConnectionContext context, MessageReference messageReference)Called when message is delivered to the brokervoidDestination. messageDelivered(ConnectionContext context, MessageReference messageReference)Called when message is delivered to the brokervoidDestinationFilter. messageDelivered(ConnectionContext context, MessageReference messageReference)voidBaseDestination. messageDiscarded(ConnectionContext context, Subscription sub, MessageReference messageReference)Called when a message is discarded - e.g.voidDestination. messageDiscarded(ConnectionContext context, Subscription sub, MessageReference messageReference)Called when a message is discarded - e.g.voidDestinationFilter. messageDiscarded(ConnectionContext context, Subscription sub, MessageReference messageReference)voidDestination. messageExpired(ConnectionContext context, Subscription subs, MessageReference node)Inform the Destination a message has expiredvoidDestinationFilter. messageExpired(ConnectionContext context, PrefetchSubscription prefetchSubscription, MessageReference node)voidDestinationFilter. messageExpired(ConnectionContext context, Subscription subs, MessageReference node)voidQueue. messageExpired(ConnectionContext context, MessageReference reference)voidQueue. messageExpired(ConnectionContext context, Subscription subs, MessageReference reference)voidRegionBroker. messageExpired(ConnectionContext context, MessageReference node, Subscription subscription)voidTopic. messageExpired(ConnectionContext context, Subscription subs, MessageReference reference)protected voidPrefetchSubscription. onDispatch(MessageReference node, Message message)voidDurableTopicSubscription. removePending(MessageReference node)booleanRegionBroker. sendToDeadLetterQueue(ConnectionContext context, MessageReference node, Subscription subscription, Throwable poisonCause)protected voidPrefetchSubscription. sendToDLQ(ConnectionContext context, MessageReference node, Throwable poisonCause)protected booleanDurableTopicSubscription. trackedInPendingTransaction(MessageReference node)protected booleanPrefetchSubscription. trackedInPendingTransaction(MessageReference node)voidAbstractSubscription. unmatched(MessageReference node)voidDurableTopicSubscription. 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-matchedvoidSubscription. unmatched(MessageReference node)Method parameters in org.apache.activemq.broker.region with type arguments of type MessageReference Modifier and Type Method Description voidTopic. 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.cursorsFields in org.apache.activemq.broker.region.cursors declared as MessageReference Modifier and Type Field Description protected MessageReferenceAbstractPendingMessageCursor. lastMethods in org.apache.activemq.broker.region.cursors that return MessageReference Modifier and Type Method Description MessageReferenceOrderedPendingList. get(MessageId messageId)MessageReferencePendingList. get(MessageId messageId)MessageReferencePrioritizedPendingList. get(MessageId messageId)MessageReferenceQueueDispatchPendingList. get(MessageId messageId)MessageReferenceAbstractPendingMessageCursor. next()MessageReferenceAbstractStoreCursor. next()MessageReferenceFilePendingMessageCursor. next()MessageReferencePendingMessageCursor. next()MessageReferenceStoreDurableSubscriberCursor. next()MessageReferenceStoreQueueCursor. next()MessageReferenceVMPendingMessageCursor. 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 voidAbstractPendingMessageCursor. addMessageFirst(MessageReference node)voidAbstractStoreCursor. addMessageFirst(MessageReference node)voidFilePendingMessageCursor. addMessageFirst(MessageReference node)add message to await dispatchPendingNodeOrderedPendingList. addMessageFirst(MessageReference message)PendingNodePendingList. addMessageFirst(MessageReference message)Adds the given message to the head of the list.voidPendingMessageCursor. addMessageFirst(MessageReference node)add message to await dispatchPendingNodePrioritizedPendingList. addMessageFirst(MessageReference message)PendingNodeQueueDispatchPendingList. addMessageFirst(MessageReference message)Messages added are added directly to the pagedInPendingDispatch set of messages.voidStoreDurableSubscriberCursor. addMessageFirst(MessageReference node)voidStoreQueueCursor. addMessageFirst(MessageReference node)voidVMPendingMessageCursor. addMessageFirst(MessageReference node)add message to await dispatchbooleanAbstractPendingMessageCursor. addMessageLast(MessageReference node)PendingNodeOrderedPendingList. addMessageLast(MessageReference message)PendingNodePendingList. addMessageLast(MessageReference message)Adds the given message to the tail of the list.booleanPendingMessageCursor. addMessageLast(MessageReference node)add message to await dispatchPendingNodePrioritizedPendingList. addMessageLast(MessageReference message)PendingNodeQueueDispatchPendingList. addMessageLast(MessageReference message)Messages added are added directly to the pagedInPendingDispatch set of messages.voidAbstractPendingMessageCursor. addRecoveredMessage(MessageReference node)voidPendingMessageCursor. addRecoveredMessage(MessageReference node)Add a message recovered from a retroactive policyvoidStoreDurableSubscriberCursor. addRecoveredMessage(MessageReference node)voidPendingMessageHelper. addToMap(MessageReference message, PendingNode node)booleanOrderedPendingList. contains(MessageReference message)booleanPendingList. contains(MessageReference message)Query the PendingList to determine if the given message is contained within.booleanPrioritizedPendingList. contains(MessageReference message)booleanQueueDispatchPendingList. contains(MessageReference message)protected OrderedPendingListPrioritizedPendingList. getList(MessageReference msg)protected intPrioritizedPendingList. getPriority(MessageReference message)voidAbstractPendingMessageCursor. remove(MessageReference node)voidAbstractStoreCursor. remove(MessageReference node)voidFilePendingMessageCursor. remove(MessageReference node)PendingNodeOrderedPendingList. remove(MessageReference message)PendingNodePendingList. remove(MessageReference message)Removes the given MessageReference from the PendingList if it is contained within.voidPendingMessageCursor. remove(MessageReference node)remove a nodePendingNodePrioritizedPendingList. remove(MessageReference message)PendingNodeQueueDispatchPendingList. remove(MessageReference message)voidStoreDurableSubscriberCursor. remove(MessageReference node)voidStoreQueueCursor. remove(MessageReference node)voidVMPendingMessageCursor. remove(MessageReference node)PendingNodePendingMessageHelper. removeFromMap(MessageReference message)booleanAbstractPendingMessageCursor. tryAddMessageLast(MessageReference node, long maxWaitTime)booleanAbstractStoreCursor. tryAddMessageLast(MessageReference node, long wait)booleanFilePendingMessageCursor. tryAddMessageLast(MessageReference node, long maxWaitTime)add message to await dispatchbooleanPendingMessageCursor. tryAddMessageLast(MessageReference node, long maxWaitTime)add message to await dispatch - if it canbooleanStoreDurableSubscriberCursor. tryAddMessageLast(MessageReference node, long wait)booleanStoreQueueCursor. tryAddMessageLast(MessageReference node, long maxWait)booleanVMPendingMessageCursor. 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 voidQueueDispatchPendingList. addForRedelivery(List<MessageReference> list, boolean noConsumers)voidOrderedPendingList. 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.policyMethods 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 booleanFixedCountSubscriptionRecoveryPolicy. add(ConnectionContext context, MessageReference node)booleanFixedSizedSubscriptionRecoveryPolicy. add(ConnectionContext context, MessageReference message)booleanLastImageSubscriptionRecoveryPolicy. add(ConnectionContext context, MessageReference node)booleanNoSubscriptionRecoveryPolicy. add(ConnectionContext context, MessageReference node)booleanQueryBasedSubscriptionRecoveryPolicy. add(ConnectionContext context, MessageReference message)booleanRetainedMessageSubscriptionRecoveryPolicy. add(ConnectionContext context, MessageReference node)booleanSubscriptionRecoveryPolicy. add(ConnectionContext context, MessageReference message)A message was sent to the destination.booleanTimedSubscriptionRecoveryPolicy. add(ConnectionContext context, MessageReference message)booleanDispatchSelector. canDispatch(Subscription subscription, MessageReference node)return true if a subscription can dispatch a message referencebooleanSimpleDispatchSelector. canDispatch(Subscription subscription, MessageReference node)booleanClientIdFilterDispatchPolicy. dispatch(MessageReference node, MessageEvaluationContext msgContext, List<Subscription> consumers)booleanDispatchPolicy. dispatch(MessageReference node, MessageEvaluationContext msgContext, List<Subscription> consumers)Decides how to dispatch a selected message to a collection of consumers.booleanPriorityDispatchPolicy. dispatch(MessageReference node, MessageEvaluationContext msgContext, List<Subscription> consumers)booleanPriorityNetworkDispatchPolicy. dispatch(MessageReference node, MessageEvaluationContext msgContext, List<Subscription> consumers)booleanRoundRobinDispatchPolicy. dispatch(MessageReference node, MessageEvaluationContext msgContext, List<Subscription> consumers)booleanSimpleDispatchPolicy. dispatch(MessageReference node, MessageEvaluationContext msgContext, List<Subscription> consumers)booleanStrictOrderDispatchPolicy. dispatch(MessageReference node, MessageEvaluationContext msgContext, List consumers)
- 
Uses of MessageReference in org.apache.activemq.broker.utilMethods in org.apache.activemq.broker.util with parameters of type MessageReference Modifier and Type Method Description voidLoggingBrokerPlugin. messageConsumed(ConnectionContext context, MessageReference messageReference)voidLoggingBrokerPlugin. messageDelivered(ConnectionContext context, MessageReference messageReference)voidLoggingBrokerPlugin. messageDiscarded(ConnectionContext context, Subscription sub, MessageReference messageReference)voidLoggingBrokerPlugin. messageExpired(ConnectionContext context, MessageReference message, Subscription subscription)booleanLoggingBrokerPlugin. sendToDeadLetterQueue(ConnectionContext context, MessageReference messageReference, Subscription subscription, Throwable poisonCause)booleanRedeliveryPlugin. sendToDeadLetterQueue(ConnectionContext context, MessageReference messageReference, Subscription subscription, Throwable poisonCause)
- 
Uses of MessageReference in org.apache.activemq.commandClasses in org.apache.activemq.command that implement MessageReference Modifier and Type Class Description classActiveMQBlobMessageAn implementation ofBlobMessagefor out of band BLOB transferclassActiveMQBytesMessageABytesMessageobject is used to send a message containing a stream of uninterpreted bytes.classActiveMQMapMessageAMapMessageobject is used to send a set of name-value pairs.classActiveMQMessageclassActiveMQObjectMessageAnObjectMessageobject is used to send a message that contains a serializable object in the Java programming language ("Java object").classActiveMQStreamMessageAStreamMessageobject is used to send a stream of primitive types in the Java programming language.classActiveMQTextMessageclassMessageRepresents an ActiveMQ message
- 
Uses of MessageReference in org.apache.activemq.filterFields in org.apache.activemq.filter declared as MessageReference Modifier and Type Field Description protected MessageReferenceMessageEvaluationContext. messageReferenceMethods in org.apache.activemq.filter that return MessageReference Modifier and Type Method Description MessageReferenceMessageEvaluationContext. getMessageReference()Methods in org.apache.activemq.filter with parameters of type MessageReference Modifier and Type Method Description voidMessageEvaluationContext. setMessageReference(MessageReference messageReference)voidNonCachedMessageEvaluationContext. setMessageReference(MessageReference messageReference)
- 
Uses of MessageReference in org.apache.activemq.memory.bufferMethods 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 voidMessageQueue. add(MessageReference messageRef)Method parameters in org.apache.activemq.memory.buffer with type arguments of type MessageReference Modifier and Type Method Description voidMessageQueue. appendMessages(List<MessageReference> answer)
- 
Uses of MessageReference in org.apache.activemq.memory.listMethods 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 voidDestinationBasedMessageList. add(MessageReference node)voidMessageList. add(MessageReference node)voidSimpleMessageList. add(MessageReference node)
- 
Uses of MessageReference in org.apache.activemq.pluginMethods in org.apache.activemq.plugin with parameters of type MessageReference Modifier and Type Method Description booleanDiscardingDLQBroker. sendToDeadLetterQueue(ConnectionContext ctx, MessageReference msgRef, Subscription subscription, Throwable poisonCause)
 
-