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 booleanActiveMQConnection. isDuplicate(ActiveMQDispatcher dispatcher, Message message)protected voidActiveMQConnection. 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 booleanProducerBrokerExchange. canDispatch(Message messageSend)Enforce duplicate suppression using info from persistence adapterResponseTransportConnection. processMessage(Message messageSend)voidBrokerBroadcaster. send(ProducerBrokerExchange producerExchange, Message messageSend)voidBrokerFilter. send(ProducerBrokerExchange producerExchange, Message messageSend)voidCompositeDestinationBroker. send(ProducerBrokerExchange producerExchange, Message message)voidEmptyBroker. send(ProducerBrokerExchange producerExchange, Message message)voidErrorBroker. send(ProducerBrokerExchange producerExchange, Message message)voidTransactionBroker. send(ProducerBrokerExchange producerExchange, Message message)voidUserIDBroker. 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 voidMessageInterceptorRegistry. injectMessage(ProducerBrokerExchange producerExchange, Message messageSend)Re-inject into the Broker chainvoidMessageInterceptor. 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 voidManagedRegionBroker. 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()MessageIndirectMessageReference. getMessage()MessageMessageReference. getMessage()MessageNullMessageReference. getMessage()MessageIndirectMessageReference. getMessageHardRef()MessageMessageReference. getMessageHardRef()MessageNullMessageReference. getMessageHardRef()MessageTopic. loadMessage(MessageId messageId)Methods in org.apache.activemq.broker.region with parameters of type Message Modifier and Type Method Description protected MessageDispatchDurableTopicSubscription. createMessageDispatch(MessageReference node, Message message)protected MessageDispatchPrefetchSubscription. createMessageDispatch(MessageReference node, Message message)protected voidTopic. dispatch(ConnectionContext context, Message message)voidBaseDestination. duplicateFromStore(Message message, Subscription subscription)voidDestination. duplicateFromStore(Message message, Subscription subscription)voidDestinationFilter. duplicateFromStore(Message message, Subscription subscription)protected voidPrefetchSubscription. onDispatch(MessageReference node, Message message)protected voidBaseDestination. 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..voidAbstractRegion. send(ProducerBrokerExchange producerExchange, Message messageSend)voidDestination. send(ProducerBrokerExchange producerExchange, Message messageSend)voidDestinationFilter. send(ProducerBrokerExchange context, Message messageSend)protected voidDestinationFilter. send(ProducerBrokerExchange context, Message message, ActiveMQDestination destination)Sends a message to the given destination which may be a wildcardvoidQueue. send(ProducerBrokerExchange producerExchange, Message message)voidRegion. send(ProducerBrokerExchange producerExchange, Message message)Send a message to the broker to using the specified destination.voidRegionBroker. send(ProducerBrokerExchange producerExchange, Message message)voidTopic. send(ProducerBrokerExchange producerExchange, Message message)Method parameters in org.apache.activemq.broker.region with type arguments of type Message Modifier and Type Method Description voidQueue. doBrowse(List<Message> browseList, int max)voidTopic. doBrowse(List<Message> browseList, int max)protected voidQueue. 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 MessageFilePendingMessageCursor. getMessage(ByteSequence bs)Methods in org.apache.activemq.broker.region.cursors with parameters of type Message Modifier and Type Method Description protected booleanAbstractStoreCursor. duplicateFromStoreExcepted(Message message)protected ByteSequenceFilePendingMessageCursor. getByteSequence(Message message)static booleanAbstractStoreCursor. gotToTheStore(Message message)booleanAbstractStoreCursor. recoverMessage(Message message)booleanAbstractStoreCursor. 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 ActiveMQDestinationIndividualDeadLetterStrategy. createDestination(Message message, String prefix, String suffix, boolean useQueue, Subscription subscription)ActiveMQDestinationDeadLetterStrategy. getDeadLetterQueueFor(Message message, Subscription subscription)Returns the dead letter queue for the given message and subscription.ActiveMQDestinationIndividualDeadLetterStrategy. getDeadLetterQueueFor(Message message, Subscription subscription)ActiveMQDestinationSharedDeadLetterStrategy. getDeadLetterQueueFor(Message message, Subscription subscription)booleanAbstractDeadLetterStrategy. isSendToDeadLetterQueue(Message message)booleanDeadLetterStrategy. 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 messagesbooleanDiscardingDeadLetterStrategy. isSendToDeadLetterQueue(Message message)voidAbstractDeadLetterStrategy. rollback(Message message)voidDeadLetterStrategy. 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.booleanMessageQuery. 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 voidCompositeDestinationFilter. send(ProducerBrokerExchange context, Message message)voidVirtualTopicInterceptor. send(ProducerBrokerExchange context, Message message)protected voidVirtualTopicInterceptor. send(ProducerBrokerExchange context, Message message, ActiveMQDestination destination)protected booleanSelectorAwareVirtualTopicInterceptor. 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 booleanVirtualTopicInterceptor. 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 voidSchedulerBroker. 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 voidDestinationPathSeparatorBroker. send(ProducerBrokerExchange producerExchange, Message messageSend)voidLoggingBrokerPlugin. send(ProducerBrokerExchange producerExchange, Message messageSend)voidTimeStampingBrokerPlugin. send(ProducerBrokerExchange producerExchange, Message message)voidUDPTraceBrokerPlugin. 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 voidConnectionDotFileInterceptor. 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 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.classActiveMQTextMessageFields in org.apache.activemq.command declared as Message Modifier and Type Field Description protected MessageMessageDispatch. messageMethods in org.apache.activemq.command that return Message Modifier and Type Method Description MessageActiveMQBlobMessage. copy()MessageActiveMQBytesMessage. copy()MessageActiveMQMapMessage. copy()MessageActiveMQMessage. copy()MessageActiveMQObjectMessage. copy()MessageActiveMQStreamMessage. copy()MessageActiveMQTextMessage. copy()abstract MessageMessage. copy()MessageMessage. getMessage()MessageMessageDispatch. getMessage()MessageMessage. getMessageHardRef()Methods in org.apache.activemq.command with parameters of type Message Modifier and Type Method Description protected voidMessage. copy(Message copy)static booleanNetworkBridgeFilter. isAdvisoryInterpretedByNetworkBridge(Message message)protected booleanNetworkBridgeFilter. matchesForwardingFilter(Message message, MessageEvaluationContext mec)voidMessageDispatch. 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 MessageMessageEvaluationContext. messageMethods in org.apache.activemq.filter that return Message Modifier and Type Method Description MessageMessageEvaluationContext. getMessage()MessageNonCachedMessageEvaluationContext. getMessage()Methods in org.apache.activemq.filter with parameters of type Message Modifier and Type Method Description booleanJAXPXPathEvaluator. evaluate(Message message)ObjectPropertyExpression. evaluate(Message message)booleanXalanXPathEvaluator. evaluate(Message message)booleanXPathExpression.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 MessageDemandForwardingBridgeSupport. configureMessage(MessageDispatch md)Methods in org.apache.activemq.network with parameters of type Message Modifier and Type Method Description protected booleanDemandForwardingBridgeSupport. canDuplexDispatch(Message message)voidMBeanBridgeDestination. onInboundMessage(Message message)voidMBeanNetworkListener. onInboundMessage(NetworkBridge bridge, Message message)voidNetworkBridgeListener. onInboundMessage(NetworkBridge bridge, Message message)Called for when a message arrives over the networkvoidMBeanBridgeDestination. onOutboundMessage(Message message)voidMBeanNetworkListener. onOutboundMessage(NetworkBridge bridge, Message message)voidNetworkBridgeListener. onOutboundMessage(NetworkBridge bridge, Message message)Called when message forwarded over the networkprotected voidDemandForwardingBridgeSupport. serviceInboundMessage(Message message)protected voidDemandForwardingBridgeSupport. 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 voidPartitionBroker. 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 voidForcePersistencyModeBroker. send(ProducerBrokerExchange producerExchange, Message messageSend)Sets the persistence modevoidStatisticsBroker. 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 booleanMessageAuthorizationPolicy. isAllowedToConsume(ConnectionContext context, Message message)Returns true if the given message is able to be dispatched to the connection performing any uservoidAuthorizationBroker. 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 voidAuthorizationFilter. 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 ResponseCommandVisitor. processMessage(Message send)ResponseCommandVisitorAdapter. processMessage(Message send)ResponseConnectionStateTracker. 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 MessageIndexListener.MessageContext. messageMethods in org.apache.activemq.store that return Message Modifier and Type Method Description MessageMessageStore. getMessage(MessageId identity)Looks up a message using either the String messageID or the messageNumber.MessageProxyMessageStore. getMessage(MessageId identity)MessageProxyTopicMessageStore. getMessage(MessageId identity)Methods in org.apache.activemq.store with parameters of type Message Modifier and Type Method Description voidAbstractMessageStore. addMessage(ConnectionContext context, Message message, boolean canOptimizeHint)voidMessageStore. addMessage(ConnectionContext context, Message message)Adds a message to the message storevoidMessageStore. addMessage(ConnectionContext context, Message message, boolean canOptimizeHint)Adds a message to the message storevoidProxyMessageStore. addMessage(ConnectionContext context, Message message)voidProxyMessageStore. addMessage(ConnectionContext context, Message message, boolean canOptimizeHint)voidProxyTopicMessageStore. addMessage(ConnectionContext context, Message message)voidProxyTopicMessageStore. 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)voidTransactionRecoveryListener. recover(XATransactionId xid, Message[] addedMessages, MessageAck[] aks)booleanMessageRecoveryListener. recoverMessage(Message message)voidAbstractMessageStore. updateMessage(Message message)voidMessageStore. updateMessage(Message message)voidProxyMessageStore. updateMessage(Message message)voidProxyTopicMessageStore. 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. rolledBackAcksMethods in org.apache.activemq.store.jdbc that return Message Modifier and Type Method Description MessageJDBCMessageStore. getMessage(MessageId messageId)Methods in org.apache.activemq.store.jdbc with parameters of type Message Modifier and Type Method Description voidJDBCMessageStore. addMessage(ConnectionContext context, Message message)protected voidJDBCMessageStore. onAdd(Message message, long sequenceId, byte priority)protected voidJDBCTopicMessageStore. onAdd(Message message, long sequenceId, byte priority)voidJDBCMessageStore. trackRollbackAck(Message message)voidJDBCMessageStore. 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 MessageJournalMessageStore. getMessage(MessageId identity)Message[]JournalTransactionStore.Tx. getMessages()Methods in org.apache.activemq.store.journal with parameters of type Message Modifier and Type Method Description voidJournalTransactionStore.Tx. add(JournalMessageStore store, Message msg)voidJournalMessageStore. 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.voidJournalTopicMessageStore. addMessage(ConnectionContext context, Message message)voidJournalMessageStore. 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 MessageKahaDBStore.KahaDBMessageStore. getMessage(MessageId identity)MessageTempKahaDBStore.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 voidKahaDBStore.KahaDBMessageStore. addMessage(ConnectionContext context, Message message)voidTempKahaDBStore.KahaDBMessageStore. addMessage(ConnectionContext context, Message message)ListenableFuture<Object>KahaDBStore.KahaDBMessageStore. asyncAddQueueMessage(ConnectionContext context, Message message)voidKahaDBStore.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. messageTableMethods in org.apache.activemq.store.memory that return Message Modifier and Type Method Description MessageMemoryMessageStore. getMessage(MessageId identity)MessageMemoryTransactionStore.AddMessageCommand. getMessage()Message[]MemoryTransactionStore.Tx. getMessages()Methods in org.apache.activemq.store.memory with parameters of type Message Modifier and Type Method Description voidMemoryMessageStore. addMessage(ConnectionContext context, Message message)voidMemoryTopicMessageStore. addMessage(ConnectionContext context, Message message)protected static voidMemoryMessageStore. decMessageStoreStatistics(MessageStoreStatistics stats, Message message)protected static voidMemoryMessageStore. incMessageStoreStatistics(MessageStoreStatistics stats, Message message)voidMemoryMessageStore. 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 voidBrokerSupport. doResend(ConnectionContext context, Message originalMessage, ActiveMQDestination deadLetterDestination, boolean copy)static voidBrokerSupport. resend(ConnectionContext context, Message originalMessage, ActiveMQDestination deadLetterDestination)static voidBrokerSupport. resendNoCopy(ConnectionContext context, Message originalMessage, ActiveMQDestination deadLetterDestination)
-