Uses of Class
org.apache.activemq.command.ActiveMQDestination
-
Packages that use ActiveMQDestination 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.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.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.junit org.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.plugin.java org.apache.activemq.ra JCA managed connections and resource adapters for working with ActiveMQorg.apache.activemq.security Plugable Security Adapter framework along with default implementations such as the JAAS implementation.org.apache.activemq.shiro.authz org.apache.activemq.shiro.subject 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.jdbc.adapter Implements database/driver apapters to compensate for the wide differences in the BLOB handing of JDBC drivers.org.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.transport.amqp A Broker side implementation of the AMQP 3.1 protocol - see http://amqp.org/org.apache.activemq.transport.amqp.protocol org.apache.activemq.transport.mqtt A Broker side implementation of the MQTT 3.1 protocol - see http://mqtt.org/org.apache.activemq.transport.mqtt.strategy org.apache.activemq.transport.stomp An implementation of the Stomp protocol which is a simple wire protocol for writing clients for ActiveMQ in different languages like Ruby, Python, PHP, C etc.org.apache.activemq.util org.apache.activemq.web Web Connectors so that messages can be sent via HTTP POST or read via HTTP POST or GET as well as support for web streaming to web browser or JavaScript clients.org.apache.activemq.web.controller -
-
Uses of ActiveMQDestination in org.apache.activemq
Methods in org.apache.activemq that return ActiveMQDestination Modifier and Type Method Description protected ActiveMQDestination
ActiveMQMessageConsumer. getDestination()
static ActiveMQDestination
ActiveMQMessageTransformation. transformDestination(Destination destination)
Creates a an available JMS message from another provider.Methods in org.apache.activemq with parameters of type ActiveMQDestination Modifier and Type Method Description void
ActiveMQConnection. destroyDestination(ActiveMQDestination destination)
boolean
ActiveMQConnection. isDeleted(ActiveMQDestination dest)
protected void
ActiveMQSession. send(ActiveMQMessageProducer producer, ActiveMQDestination destination, Message message, int deliveryMode, int priority, long timeToLive, MemoryUsage producerWindow, int sendTimeout, AsyncCallback onComplete)
Sends the message for dispatch by the broker.Constructors in org.apache.activemq with parameters of type ActiveMQDestination Constructor Description ActiveMQMessageConsumer(ActiveMQSession session, ConsumerId consumerId, ActiveMQDestination dest, String name, String selector, int prefetch, int maximumPendingMessageCount, boolean noLocal, boolean browser, boolean dispatchAsync, MessageListener messageListener)
Create a MessageConsumerActiveMQMessageProducer(ActiveMQSession session, ProducerId producerId, ActiveMQDestination destination, int sendTimeout)
ActiveMQQueueBrowser(ActiveMQSession session, ConsumerId consumerId, ActiveMQDestination destination, String selector, boolean dispatchAsync)
Constructor for an ActiveMQQueueBrowser - used internallyActiveMQQueueReceiver(ActiveMQSession theSession, ConsumerId consumerId, ActiveMQDestination destination, String selector, int prefetch, int maximumPendingMessageCount, boolean asyncDispatch)
ActiveMQQueueSender(ActiveMQSession session, ActiveMQDestination destination, int sendTimeout)
ActiveMQTopicPublisher(ActiveMQSession session, ActiveMQDestination destination, int sendTimeout)
ActiveMQTopicSubscriber(ActiveMQSession theSession, ConsumerId consumerId, ActiveMQDestination dest, String name, String selector, int prefetch, int maximumPendingMessageCount, boolean noLocalValue, boolean browserValue, boolean asyncDispatch)
-
Uses of ActiveMQDestination in org.apache.activemq.advisory
Fields in org.apache.activemq.advisory with type parameters of type ActiveMQDestination Modifier and Type Field Description protected ConcurrentMap<ActiveMQDestination,DestinationInfo>
AdvisoryBroker. destinations
Methods in org.apache.activemq.advisory that return ActiveMQDestination Modifier and Type Method Description ActiveMQDestination
DestinationEvent. getDestination()
Methods in org.apache.activemq.advisory that return types with arguments of type ActiveMQDestination Modifier and Type Method Description Map<ActiveMQDestination,DestinationInfo>
AdvisoryBroker. getAdvisoryDestinations()
Constructors in org.apache.activemq.advisory with parameters of type ActiveMQDestination Constructor Description ConsumerStartedEvent(ConsumerEventSource source, ActiveMQDestination destination, ConsumerInfo consumerInfo, int count)
ConsumerStoppedEvent(ConsumerEventSource source, ActiveMQDestination destination, ConsumerId consumerId, int count)
ProducerStartedEvent(ProducerEventSource source, ActiveMQDestination destination, ProducerInfo consumerInfo, int count)
ProducerStoppedEvent(ProducerEventSource source, ActiveMQDestination destination, ProducerId consumerId, int count)
-
Uses of ActiveMQDestination in org.apache.activemq.broker
Methods in org.apache.activemq.broker that return ActiveMQDestination Modifier and Type Method Description ActiveMQDestination[]
Broker. getDestinations()
ActiveMQDestination[]
BrokerFilter. getDestinations()
ActiveMQDestination[]
BrokerService. getDestinations()
ActiveMQDestination[]
EmptyBroker. getDestinations()
ActiveMQDestination[]
ErrorBroker. getDestinations()
Methods in org.apache.activemq.broker with parameters of type ActiveMQDestination Modifier and Type Method Description Destination
BrokerBroadcaster. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean createIfTemporary)
Destination
BrokerFilter. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean createIfTemporary)
Destination
EmptyBroker. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean flag)
Destination
ErrorBroker. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean flag)
void
Broker. fastProducer(ConnectionContext context, ProducerInfo producerInfo, ActiveMQDestination destination)
Called to notify a producer is too fastvoid
BrokerFilter. fastProducer(ConnectionContext context, ProducerInfo producerInfo, ActiveMQDestination destination)
void
EmptyBroker. fastProducer(ConnectionContext context, ProducerInfo producerInfo, ActiveMQDestination destination)
void
ErrorBroker. fastProducer(ConnectionContext context, ProducerInfo producerInfo, ActiveMQDestination destination)
Destination
BrokerService. getDestination(ActiveMQDestination destination)
Looks up and lazily creates if necessary the destination for the given JMS nameMap<ActiveMQDestination,Destination>
Broker. getDestinationMap(ActiveMQDestination destination)
return a reference destination map of a region based on the destination typeMap<ActiveMQDestination,Destination>
BrokerFilter. getDestinationMap(ActiveMQDestination destination)
Map<ActiveMQDestination,Destination>
EmptyBroker. getDestinationMap(ActiveMQDestination destination)
Map<ActiveMQDestination,Destination>
ErrorBroker. getDestinationMap(ActiveMQDestination destination)
Set<Destination>
BrokerFilter. getDestinations(ActiveMQDestination destination)
Set<Destination>
EmptyBroker. getDestinations(ActiveMQDestination destination)
Set<Destination>
ErrorBroker. getDestinations(ActiveMQDestination destination)
void
BrokerBroadcaster. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
void
BrokerFilter. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
void
BrokerService. removeDestination(ActiveMQDestination destination)
void
EmptyBroker. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
void
ErrorBroker. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
void
BrokerService. setDestinations(ActiveMQDestination[] destinations)
Sets the destinations which should be loaded/created on startupboolean
BrokerService. shouldRecordVirtualDestination(ActiveMQDestination destination)
Method parameters in org.apache.activemq.broker with type arguments of type ActiveMQDestination Modifier and Type Method Description void
BrokerService. startNetworkConnector(NetworkConnector connector, Set<ActiveMQDestination> durableDestinations, ThreadPoolExecutor networkConnectorStartExecutor)
-
Uses of ActiveMQDestination in org.apache.activemq.broker.inteceptor
Methods in org.apache.activemq.broker.inteceptor with parameters of type ActiveMQDestination Modifier and Type Method Description MessageInterceptor
MessageInterceptorRegistry. addMessageInterceptor(ActiveMQDestination activeMQDestination, MessageInterceptor messageInterceptor)
void
MessageInterceptorRegistry. removeMessageInterceptor(ActiveMQDestination activeMQDestination, MessageInterceptor interceptor)
-
Uses of ActiveMQDestination in org.apache.activemq.broker.jmx
Fields in org.apache.activemq.broker.jmx declared as ActiveMQDestination Modifier and Type Field Description protected ActiveMQDestination
ProducerView. lastUsedDestination
Methods in org.apache.activemq.broker.jmx with parameters of type ActiveMQDestination Modifier and Type Method Description protected Destination
ManagedQueueRegion. createDestination(ConnectionContext context, ActiveMQDestination destination)
protected Destination
ManagedTempQueueRegion. createDestination(ConnectionContext context, ActiveMQDestination destination)
protected Destination
ManagedTempTopicRegion. createDestination(ConnectionContext context, ActiveMQDestination destination)
protected Destination
ManagedTopicRegion. createDestination(ConnectionContext context, ActiveMQDestination destination)
static ObjectName
BrokerMBeanSupport. createDestinationName(String brokerObjectName, ActiveMQDestination destination)
static ObjectName
BrokerMBeanSupport. createDestinationName(ObjectName brokerObjectName, ActiveMQDestination destination)
static ObjectName
BrokerMBeanSupport. createNetworkInBoundDestinationObjectName(ObjectName networkName, ActiveMQDestination destination)
static ObjectName
BrokerMBeanSupport. createNetworkOutBoundDestinationObjectName(ObjectName networkName, ActiveMQDestination destination)
boolean
SubscriptionView. matchesDestination(ActiveMQDestination destination)
Return true if this subscription matches the given destinationvoid
ManagedRegionBroker. register(ActiveMQDestination destName, Destination destination)
protected void
ManagedRegionBroker. registerDestination(ObjectName key, ActiveMQDestination dest, DestinationView view)
protected void
ManagedRegionBroker. registerProducer(ObjectName key, ActiveMQDestination dest, ProducerView view)
void
ManagedQueueRegion. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
void
ManagedTempQueueRegion. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
void
ManagedTempTopicRegion. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
void
ManagedTopicRegion. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
void
ManagedRegionBroker. unregister(ActiveMQDestination destName)
-
Uses of ActiveMQDestination in org.apache.activemq.broker.region
Fields in org.apache.activemq.broker.region declared as ActiveMQDestination Modifier and Type Field Description protected ActiveMQDestination
BaseDestination. destination
Fields in org.apache.activemq.broker.region with type parameters of type ActiveMQDestination Modifier and Type Field Description protected Map<ActiveMQDestination,Destination>
AbstractRegion. destinations
Methods in org.apache.activemq.broker.region that return ActiveMQDestination Modifier and Type Method Description ActiveMQDestination
AbstractSubscription. getActiveMQDestination()
ActiveMQDestination
BaseDestination. getActiveMQDestination()
ActiveMQDestination
Destination. getActiveMQDestination()
ActiveMQDestination
DestinationFilter. getActiveMQDestination()
ActiveMQDestination
Queue. getActiveMQDestination()
ActiveMQDestination
SubscriptionRecovery. getActiveMQDestination()
ActiveMQDestination[]
RegionBroker. getDestinations()
Methods in org.apache.activemq.broker.region with parameters of type ActiveMQDestination Modifier and Type Method Description Destination
AbstractRegion. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean createIfTemporary)
Destination
Region. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean createIfTemporary)
Used to create a destination.Destination
RegionBroker. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean createIfTemp)
protected void
DestinationFactoryImpl. configureQueue(Queue queue, ActiveMQDestination destination)
protected void
DestinationFactoryImpl. configureTopic(Topic topic, ActiveMQDestination destination)
protected void
TopicRegion. configureTopic(Topic topic, ActiveMQDestination destination)
int
Queue. copyMatchingMessages(ConnectionContext context, MessageReferenceFilter filter, ActiveMQDestination dest, int maximumMessages)
Copies the messages matching the given filter up to the maximum number of matched messagesint
Queue. copyMatchingMessagesTo(ConnectionContext context, String selector, ActiveMQDestination dest)
Copies the messages matching the given selectorint
Queue. copyMatchingMessagesTo(ConnectionContext context, String selector, ActiveMQDestination dest, int maximumMessages)
Copies the messages matching the given selector up to the maximum number of matched messagesboolean
Queue. copyMessageTo(ConnectionContext context, String messageId, ActiveMQDestination dest)
Copies the message matching the given messageIdvoid
CompositeDestinationInterceptor. create(Broker broker, ConnectionContext context, ActiveMQDestination destination)
void
DestinationInterceptor. create(Broker broker, ConnectionContext context, ActiveMQDestination destination)
protected Destination
AbstractRegion. createDestination(ConnectionContext context, ActiveMQDestination destination)
protected Destination
AbstractTempRegion. createDestination(ConnectionContext context, ActiveMQDestination destination)
abstract Destination
DestinationFactory. createDestination(ConnectionContext context, ActiveMQDestination destination, DestinationStatistics destinationStatistics)
Create destination implementation.Destination
DestinationFactoryImpl. createDestination(ConnectionContext context, ActiveMQDestination destination, DestinationStatistics destinationStatistics)
protected JMSException
RegionBroker. createUnknownDestinationTypeException(ActiveMQDestination destination)
Map<ActiveMQDestination,Destination>
RegionBroker. getDestinationMap(ActiveMQDestination destination)
Set<Destination>
AbstractRegion. getDestinations(ActiveMQDestination destination)
Provide an exact or wildcard lookup of destinations in the regionSet<Destination>
Region. getDestinations(ActiveMQDestination destination)
Provide an exact or wildcard lookup of destinations in the regionSet<Destination>
RegionBroker. getDestinations(ActiveMQDestination destination)
Region
RegionBroker. getRegion(ActiveMQDestination destination)
protected Destination
AbstractRegion. lookup(ConnectionContext context, ActiveMQDestination destination, boolean createTemporary)
boolean
AbstractSubscription. matches(ActiveMQDestination destination)
boolean
Subscription. matches(ActiveMQDestination destination)
Is the subscription interested in messages in the destination?int
Queue. moveMatchingMessagesTo(ConnectionContext context, String selector, ActiveMQDestination dest)
Moves the messages matching the given selectorint
Queue. moveMatchingMessagesTo(ConnectionContext context, String selector, ActiveMQDestination dest, int maximumMessages)
Moves the messages matching the given selector up to the maximum number of matched messagesint
Queue. moveMatchingMessagesTo(ConnectionContext context, MessageReferenceFilter filter, ActiveMQDestination dest, int maximumMessages)
Moves the messages matching the given filter up to the maximum number of matched messagesboolean
Queue. moveMessageTo(ConnectionContext context, String messageId, ActiveMQDestination dest)
Moves the message matching the given messageIdboolean
Queue. moveMessageTo(ConnectionContext context, QueueMessageReference m, ActiveMQDestination dest)
Move a messagevoid
AbstractRegion. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
void
Region. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
Used to destroy a destination.void
RegionBroker. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
void
TempQueueRegion. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
void
TempTopicRegion. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
protected void
DestinationFilter. send(ProducerBrokerExchange context, Message message, ActiveMQDestination destination)
Sends a message to the given destination which may be a wildcardprotected void
AbstractRegion. updateRegionDestCounts(ActiveMQDestination destination, int count)
Updates the counts in RegionStatistics based on whether or not the destination is an Advisory Destination or notprotected void
AbstractRegion. validateMaxDestinations(ActiveMQDestination destination)
This method checks whether or not the destination can be created based onPolicyEntry.getMaxDestinations()
, if it has been set.Constructors in org.apache.activemq.broker.region with parameters of type ActiveMQDestination Constructor Description BaseDestination(BrokerService brokerService, MessageStore store, ActiveMQDestination destination, DestinationStatistics parentStats)
Queue(BrokerService brokerService, ActiveMQDestination destination, MessageStore store, DestinationStatistics parentStats, TaskRunnerFactory taskFactory)
QueueDispatchSelector(ActiveMQDestination destination)
TempQueue(BrokerService brokerService, ActiveMQDestination destination, MessageStore store, DestinationStatistics parentStats, TaskRunnerFactory taskFactory)
TempTopic(BrokerService brokerService, ActiveMQDestination destination, TopicMessageStore store, DestinationStatistics parentStats, TaskRunnerFactory taskFactory)
Topic(BrokerService brokerService, ActiveMQDestination destination, TopicMessageStore store, DestinationStatistics parentStats, TaskRunnerFactory taskFactory)
-
Uses of ActiveMQDestination in org.apache.activemq.broker.region.policy
Methods in org.apache.activemq.broker.region.policy that return ActiveMQDestination Modifier and Type Method Description protected ActiveMQDestination
IndividualDeadLetterStrategy. createDestination(Message message, String prefix, String suffix, boolean useQueue, Subscription subscription)
ActiveMQDestination
SharedDeadLetterStrategy. getDeadLetterQueue()
ActiveMQDestination
DeadLetterStrategy. getDeadLetterQueueFor(Message message, Subscription subscription)
Returns the dead letter queue for the given message and subscription.ActiveMQDestination
IndividualDeadLetterStrategy. getDeadLetterQueueFor(Message message, Subscription subscription)
ActiveMQDestination
SharedDeadLetterStrategy. getDeadLetterQueueFor(Message message, Subscription subscription)
Methods in org.apache.activemq.broker.region.policy with parameters of type ActiveMQDestination 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)
void
MessageQuery. execute(ActiveMQDestination destination, MessageListener listener)
Executes the query for messages; each message is passed into the listenerPolicyEntry
PolicyMap. getEntryFor(ActiveMQDestination destination)
RedeliveryPolicy
RedeliveryPolicyMap. getEntryFor(ActiveMQDestination destination)
void
SharedDeadLetterStrategy. setDeadLetterQueue(ActiveMQDestination deadLetterQueue)
Constructors in org.apache.activemq.broker.region.policy with parameters of type ActiveMQDestination Constructor Description SimpleDispatchSelector(ActiveMQDestination destination)
-
Uses of ActiveMQDestination in org.apache.activemq.broker.region.virtual
Methods in org.apache.activemq.broker.region.virtual that return ActiveMQDestination Modifier and Type Method Description ActiveMQDestination
FilteredDestination. getDestination()
ActiveMQDestination
CompositeDestination. getMappedDestinations()
ActiveMQDestination
VirtualDestination. getMappedDestinations()
Returns mapped destination(s)ActiveMQDestination
VirtualTopic. getMappedDestinations()
protected ActiveMQDestination
MirroredQueue. getMirrorTopic(ActiveMQDestination original)
protected ActiveMQDestination
VirtualTopicInterceptor. getQueueConsumersWildcard(ActiveMQDestination original)
ActiveMQDestination
CompositeQueue. getVirtualDestination()
ActiveMQDestination
CompositeTopic. getVirtualDestination()
ActiveMQDestination
VirtualDestination. getVirtualDestination()
Returns the virtual destinationActiveMQDestination
VirtualTopic. getVirtualDestination()
Methods in org.apache.activemq.broker.region.virtual with parameters of type ActiveMQDestination Modifier and Type Method Description void
CompositeDestination. create(Broker broker, ConnectionContext context, ActiveMQDestination destination)
void
MirroredQueue. create(Broker broker, ConnectionContext context, ActiveMQDestination destination)
void
VirtualDestinationInterceptor. create(Broker broker, ConnectionContext context, ActiveMQDestination destination)
void
VirtualTopic. create(Broker broker, ConnectionContext context, ActiveMQDestination destination)
protected ActiveMQDestination
MirroredQueue. getMirrorTopic(ActiveMQDestination original)
protected ActiveMQDestination
VirtualTopicInterceptor. getQueueConsumersWildcard(ActiveMQDestination original)
protected void
VirtualTopicInterceptor. send(ProducerBrokerExchange context, Message message, ActiveMQDestination destination)
void
FilteredDestination. setDestination(ActiveMQDestination destination)
The destination to send messages to if they match the filterConstructors in org.apache.activemq.broker.region.virtual with parameters of type ActiveMQDestination Constructor Description MappedQueueFilter(ActiveMQDestination virtualDestination, Destination destination)
-
Uses of ActiveMQDestination in org.apache.activemq.broker.scheduler
Methods in org.apache.activemq.broker.scheduler with parameters of type ActiveMQDestination Modifier and Type Method Description protected void
SchedulerBroker. sendScheduledJob(ConnectionContext context, Job job, ActiveMQDestination replyTo)
-
Uses of ActiveMQDestination in org.apache.activemq.broker.util
Methods in org.apache.activemq.broker.util that return ActiveMQDestination Modifier and Type Method Description protected ActiveMQDestination
DestinationPathSeparatorBroker. convertDestination(ActiveMQDestination destination)
ActiveMQDestination[]
LoggingBrokerPlugin. getDestinations()
Methods in org.apache.activemq.broker.util that return types with arguments of type ActiveMQDestination Modifier and Type Method Description Set<ActiveMQDestination>
LoggingBrokerPlugin. getDurableDestinations()
Methods in org.apache.activemq.broker.util with parameters of type ActiveMQDestination Modifier and Type Method Description Destination
DestinationPathSeparatorBroker. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean createIfTemporary)
Destination
DestinationsPlugin. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean createIfTemporary)
Destination
LoggingBrokerPlugin. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean create)
protected ActiveMQDestination
DestinationPathSeparatorBroker. convertDestination(ActiveMQDestination destination)
void
LoggingBrokerPlugin. fastProducer(ConnectionContext context, ProducerInfo producerInfo, ActiveMQDestination destination)
void
DestinationPathSeparatorBroker. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
void
DestinationsPlugin. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
void
LoggingBrokerPlugin. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
void
UDPTraceBrokerPlugin. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
-
Uses of ActiveMQDestination in org.apache.activemq.broker.view
Methods in org.apache.activemq.broker.view that return types with arguments of type ActiveMQDestination Modifier and Type Method Description Set<ActiveMQDestination>
MessageBrokerView. getDestinations()
Retrieve a set of all Destinations be used by the BrokerMethods in org.apache.activemq.broker.view with parameters of type ActiveMQDestination Modifier and Type Method Description Destination
DestinationDotFileInterceptor. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean create)
BrokerDestinationView
MessageBrokerView. getDestinationView(ActiveMQDestination activeMQDestination)
Get the BrokerDestinationView associated with destinationvoid
DestinationDotFileInterceptor. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
-
Uses of ActiveMQDestination in org.apache.activemq.command
Subclasses of ActiveMQDestination in org.apache.activemq.command Modifier and Type Class Description class
ActiveMQQueue
class
ActiveMQTempDestination
class
ActiveMQTempQueue
class
ActiveMQTempTopic
class
ActiveMQTopic
Fields in org.apache.activemq.command declared as ActiveMQDestination Modifier and Type Field Description protected ActiveMQDestination[]
ActiveMQDestination. compositeDestinations
protected ActiveMQDestination
ConsumerControl. destination
protected ActiveMQDestination
ConsumerInfo. destination
protected ActiveMQDestination
DestinationInfo. destination
protected ActiveMQDestination
Message. destination
protected ActiveMQDestination
MessageAck. destination
protected ActiveMQDestination
MessageDispatch. destination
protected ActiveMQDestination
MessageDispatchNotification. destination
protected ActiveMQDestination
MessagePull. destination
protected ActiveMQDestination
ProducerInfo. destination
protected ActiveMQDestination
SubscriptionInfo. destination
protected ActiveMQDestination
Message. originalDestination
protected ActiveMQDestination
Message. replyTo
protected ActiveMQDestination
SubscriptionInfo. subscribedDestination
Methods in org.apache.activemq.command that return ActiveMQDestination Modifier and Type Method Description ActiveMQDestination
ActiveMQDestination. createDestination(String name)
static ActiveMQDestination
ActiveMQDestination. createDestination(String name, byte defaultType)
ActiveMQDestination[]
ActiveMQDestination. getCompositeDestinations()
ActiveMQDestination
ConsumerControl. getDestination()
ActiveMQDestination
ConsumerInfo. getDestination()
The destination that the consumer is interested in receiving messages from.ActiveMQDestination
DestinationInfo. getDestination()
ActiveMQDestination
JournalQueueAck. getDestination()
ActiveMQDestination
JournalTopicAck. getDestination()
ActiveMQDestination
Message. getDestination()
ActiveMQDestination
MessageAck. getDestination()
ActiveMQDestination
MessageDispatch. getDestination()
ActiveMQDestination
MessageDispatchNotification. getDestination()
ActiveMQDestination
MessagePull. getDestination()
ActiveMQDestination
ProducerInfo. getDestination()
ActiveMQDestination
SubscriptionInfo. getDestination()
This is the a resolved destination that the subscription is receiving messages from.ActiveMQDestination
Message. getOriginalDestination()
ActiveMQDestination
Message. getReplyTo()
ActiveMQDestination
SubscriptionInfo. getSubscribedDestination()
The destination the client originally subscribed to..static ActiveMQDestination
ActiveMQDestination. transform(Destination dest)
ActiveMQDestination
DefaultUnresolvedDestinationTransformer. transform(String dest)
ActiveMQDestination
DefaultUnresolvedDestinationTransformer. transform(Destination dest)
ActiveMQDestination
UnresolvedDestinationTransformer. transform(String dest)
ActiveMQDestination
UnresolvedDestinationTransformer. transform(Destination dest)
Methods in org.apache.activemq.command with parameters of type ActiveMQDestination Modifier and Type Method Description void
ConsumerInfo. clearAssignedGroupCount(ActiveMQDestination dest)
static int
ActiveMQDestination. compare(ActiveMQDestination destination, ActiveMQDestination destination2)
void
ConsumerInfo. decrementAssignedGroupCount(ActiveMQDestination dest)
long
ConsumerInfo. getAssignedGroupCount(ActiveMQDestination dest)
void
ConsumerInfo. incrementAssignedGroupCount(ActiveMQDestination dest)
void
ActiveMQDestination. setCompositeDestinations(ActiveMQDestination[] destinations)
void
ConsumerControl. setDestination(ActiveMQDestination destination)
void
ConsumerInfo. setDestination(ActiveMQDestination destination)
void
DestinationInfo. setDestination(ActiveMQDestination destination)
void
JournalQueueAck. setDestination(ActiveMQDestination destination)
void
JournalTopicAck. setDestination(ActiveMQDestination destination)
void
Message. setDestination(ActiveMQDestination destination)
void
MessageAck. setDestination(ActiveMQDestination destination)
void
MessageDispatch. setDestination(ActiveMQDestination destination)
void
MessageDispatchNotification. setDestination(ActiveMQDestination destination)
void
MessagePull. setDestination(ActiveMQDestination destination)
void
ProducerInfo. setDestination(ActiveMQDestination destination)
void
SubscriptionInfo. setDestination(ActiveMQDestination destination)
void
Message. setOriginalDestination(ActiveMQDestination destination)
void
Message. setReplyTo(ActiveMQDestination replyTo)
void
SubscriptionInfo. setSubscribedDestination(ActiveMQDestination subscribedDestination)
Constructors in org.apache.activemq.command with parameters of type ActiveMQDestination Constructor Description ActiveMQDestination(ActiveMQDestination[] composites)
DestinationInfo(ConnectionId connectionId, byte operationType, ActiveMQDestination destination)
-
Uses of ActiveMQDestination in org.apache.activemq.filter
Subclasses of ActiveMQDestination in org.apache.activemq.filter Modifier and Type Class Description class
AnyDestination
Fields in org.apache.activemq.filter declared as ActiveMQDestination Modifier and Type Field Description protected ActiveMQDestination
DestinationMapEntry. destination
protected ActiveMQDestination
MessageEvaluationContext. destination
Methods in org.apache.activemq.filter that return ActiveMQDestination Modifier and Type Method Description ActiveMQDestination
DestinationMapEntry. getDestination()
ActiveMQDestination
MessageEvaluationContext. getDestination()
Methods in org.apache.activemq.filter with parameters of type ActiveMQDestination Modifier and Type Method Description DestinationMapEntry
DestinationMap. chooseValue(ActiveMQDestination destination)
Returns the value which matches the given destination or null if there is no matching value.protected Set
DestinationMap. findWildcardMatches(ActiveMQDestination key)
protected Set
DestinationMap. findWildcardMatches(ActiveMQDestination key, boolean deep)
Set
DestinationMap. get(ActiveMQDestination key)
Looks up the value(s) matching the given Destination key.static String[]
DestinationPath. getDestinationPaths(ActiveMQDestination destination)
protected DestinationMapNode
DestinationMap. getRootNode(ActiveMQDestination key)
Returns the root node for the given destination typeboolean
CompositeDestinationFilter. matches(ActiveMQDestination destination)
abstract boolean
DestinationFilter. matches(ActiveMQDestination destination)
boolean
PrefixDestinationFilter. matches(ActiveMQDestination destination)
boolean
SimpleDestinationFilter. matches(ActiveMQDestination destination)
boolean
WildcardDestinationFilter. matches(ActiveMQDestination destination)
static DestinationFilter
DestinationFilter. parseFilter(ActiveMQDestination destination)
void
DestinationMap. put(ActiveMQDestination key, Object value)
void
DestinationMap. remove(ActiveMQDestination key, Object value)
Removes the value from the associated destinationSet
DestinationMap. removeAll(ActiveMQDestination key)
void
DestinationMapEntry. setDestination(ActiveMQDestination destination)
void
MessageEvaluationContext. setDestination(ActiveMQDestination destination)
Set
DestinationMap. unsynchronizedGet(ActiveMQDestination key)
void
DestinationMap. unsynchronizedPut(ActiveMQDestination key, Object value)
void
DestinationMap. unsynchronizedRemove(ActiveMQDestination key, Object value)
Constructors in org.apache.activemq.filter with parameters of type ActiveMQDestination Constructor Description AnyDestination(ActiveMQDestination[] destinations)
CompositeDestinationFilter(ActiveMQDestination destination)
SimpleDestinationFilter(ActiveMQDestination destination)
-
Uses of ActiveMQDestination in org.apache.activemq.junit
Methods in org.apache.activemq.junit that return ActiveMQDestination Modifier and Type Method Description protected ActiveMQDestination
AbstractActiveMQClientResource. createDestination(String destinationName)
-
Uses of ActiveMQDestination in org.apache.activemq.memory.list
Methods in org.apache.activemq.memory.list with parameters of type ActiveMQDestination Modifier and Type Method Description Message[]
DestinationBasedMessageList. browse(ActiveMQDestination destination)
Message[]
MessageList. browse(ActiveMQDestination destination)
Message[]
SimpleMessageList. browse(ActiveMQDestination destination)
List<MessageReference>
DestinationBasedMessageList. getMessages(ActiveMQDestination destination)
List
MessageList. getMessages(ActiveMQDestination destination)
Returns the current list of MessageReference objects for the given subscriptionList<MessageReference>
SimpleMessageList. getMessages(ActiveMQDestination destination)
-
Uses of ActiveMQDestination in org.apache.activemq.network
Fields in org.apache.activemq.network declared as ActiveMQDestination Modifier and Type Field Description protected ActiveMQDestination[]
DemandForwardingBridgeSupport. durableDestinations
protected ActiveMQDestination[]
DemandForwardingBridgeSupport. dynamicallyIncludedDestinations
protected ActiveMQDestination[]
DemandForwardingBridgeSupport. excludedDestinations
protected ActiveMQDestination[]
DemandForwardingBridgeSupport. staticallyIncludedDestinations
Fields in org.apache.activemq.network with type parameters of type ActiveMQDestination Modifier and Type Field Description protected List<ActiveMQDestination>
NetworkBridgeConfiguration. dynamicallyIncludedDestinations
protected List<ActiveMQDestination>
NetworkBridgeConfiguration. excludedDestinations
protected List<ActiveMQDestination>
NetworkBridgeConfiguration. staticallyIncludedDestinations
Methods in org.apache.activemq.network that return ActiveMQDestination Modifier and Type Method Description ActiveMQDestination[]
DemandForwardingBridgeSupport. getDurableDestinations()
static ActiveMQDestination[]
NetworkConnector. getDurableTopicDestinations(Set<ActiveMQDestination> durableDestinations)
ActiveMQDestination[]
DemandForwardingBridgeSupport. getDynamicallyIncludedDestinations()
ActiveMQDestination[]
DemandForwardingBridgeSupport. getExcludedDestinations()
ActiveMQDestination[]
DemandForwardingBridgeSupport. getStaticallyIncludedDestinations()
Methods in org.apache.activemq.network that return types with arguments of type ActiveMQDestination Modifier and Type Method Description Set<ActiveMQDestination>
NetworkConnector. getDurableDestinations()
List<ActiveMQDestination>
NetworkBridgeConfiguration. getDynamicallyIncludedDestinations()
List<ActiveMQDestination>
NetworkBridgeConfiguration. getExcludedDestinations()
List<ActiveMQDestination>
NetworkBridgeConfiguration. getStaticallyIncludedDestinations()
Methods in org.apache.activemq.network with parameters of type ActiveMQDestination Modifier and Type Method Description void
NetworkConnector. addDynamicallyIncludedDestination(ActiveMQDestination destination)
void
NetworkConnector. addExcludedDestination(ActiveMQDestination destination)
void
NetworkConnector. addStaticallyIncludedDestination(ActiveMQDestination destination)
protected DemandSubscription
DemandForwardingBridgeSupport. createDemandSubscription(ActiveMQDestination destination, String subscriptionName)
protected boolean
DurableConduitBridge. doesConsumerExist(ActiveMQDestination dest)
protected Collection<Subscription>
DemandForwardingBridgeSupport. getRegionSubscriptions(ActiveMQDestination dest)
protected String
DurableConduitBridge. getSubscriberName(ActiveMQDestination dest)
protected boolean
DemandForwardingBridgeSupport. isPermissableDestination(ActiveMQDestination destination)
protected boolean
DemandForwardingBridgeSupport. isPermissableDestination(ActiveMQDestination destination, boolean allowTemporary)
void
DemandForwardingBridgeSupport. setDurableDestinations(ActiveMQDestination[] durableDestinations)
void
DemandForwardingBridgeSupport. setDynamicallyIncludedDestinations(ActiveMQDestination[] dynamicallyIncludedDestinations)
void
DemandForwardingBridgeSupport. setExcludedDestinations(ActiveMQDestination[] excludedDestinations)
void
DemandForwardingBridgeSupport. setStaticallyIncludedDestinations(ActiveMQDestination[] staticallyIncludedDestinations)
Method parameters in org.apache.activemq.network with type arguments of type ActiveMQDestination Modifier and Type Method Description static ActiveMQDestination[]
NetworkConnector. getDurableTopicDestinations(Set<ActiveMQDestination> durableDestinations)
void
NetworkConnector. setDurableDestinations(Set<ActiveMQDestination> durableDestinations)
void
NetworkBridgeConfiguration. setDynamicallyIncludedDestinations(List<ActiveMQDestination> dynamicallyIncludedDestinations)
void
NetworkBridgeConfiguration. setExcludedDestinations(List<ActiveMQDestination> excludedDestinations)
void
NetworkBridgeConfiguration. setStaticallyIncludedDestinations(List<ActiveMQDestination> staticallyIncludedDestinations)
-
Uses of ActiveMQDestination in org.apache.activemq.partition
Methods in org.apache.activemq.partition with parameters of type ActiveMQDestination Modifier and Type Method Description protected Target
PartitionBroker. getTarget(ActiveMQDestination dest)
-
Uses of ActiveMQDestination in org.apache.activemq.plugin
Methods in org.apache.activemq.plugin with parameters of type ActiveMQDestination Modifier and Type Method Description Destination
AbstractRuntimeConfigurationBroker. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean createIfTemporary)
protected boolean
DestinationsProcessor. containsDestination(ActiveMQDestination destination)
protected void
StatisticsBroker. sendStats(ConnectionContext context, ActiveMQMapMessage msg, ActiveMQDestination replyTo)
protected void
StatisticsBroker. sendSubStats(ConnectionContext context, ObjectName[] subscribers, ActiveMQDestination replyTo)
-
Uses of ActiveMQDestination in org.apache.activemq.plugin.java
Methods in org.apache.activemq.plugin.java with parameters of type ActiveMQDestination Modifier and Type Method Description void
JavaRuntimeConfigurationBroker. addNewDestination(ActiveMQDestination destination)
protected boolean
JavaRuntimeConfigurationBroker. containsDestination(ActiveMQDestination destination)
void
JavaRuntimeConfigurationBroker. setDestinations(ActiveMQDestination[] destinations)
-
Uses of ActiveMQDestination in org.apache.activemq.ra
Methods in org.apache.activemq.ra that return ActiveMQDestination Modifier and Type Method Description ActiveMQDestination
ActiveMQActivationSpec. createDestination()
Methods in org.apache.activemq.ra with parameters of type ActiveMQDestination Modifier and Type Method Description void
ActiveMQActivationSpec. setActiveMQDestination(ActiveMQDestination destination)
A helper method mostly for use in Dependency Injection containers which allows you to customize the destination and destinationType properties from a single ActiveMQDestination POJO -
Uses of ActiveMQDestination in org.apache.activemq.security
Fields in org.apache.activemq.security with type parameters of type ActiveMQDestination Modifier and Type Field Description protected Map<ActiveMQDestination,AuthorizationEntry>
SimpleCachedLDAPAuthorizationMap. entries
Methods in org.apache.activemq.security that return ActiveMQDestination Modifier and Type Method Description protected ActiveMQDestination
SimpleCachedLDAPAuthorizationMap. formatDestination(LdapName dn, SimpleCachedLDAPAuthorizationMap.DestinationType destinationType)
Parses a DN into the equivalentActiveMQDestination
.protected ActiveMQDestination
SimpleCachedLDAPAuthorizationMap. formatDestination(Rdn destinationName, SimpleCachedLDAPAuthorizationMap.DestinationType destinationType)
Parses RDN values representing the destination name/pattern and destination type into the equivalentActiveMQDestination
.Methods in org.apache.activemq.security that return types with arguments of type ActiveMQDestination Modifier and Type Method Description ConcurrentMap<ActiveMQDestination,ActiveMQDestination>
SecurityContext. getAuthorizedWriteDests()
ConcurrentMap<ActiveMQDestination,ActiveMQDestination>
SecurityContext. getAuthorizedWriteDests()
Methods in org.apache.activemq.security with parameters of type ActiveMQDestination Modifier and Type Method Description Destination
AuthorizationBroker. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean create)
protected boolean
AuthorizationBroker. checkDestinationAdmin(SecurityContext securityContext, ActiveMQDestination destination)
void
AuthorizationDestinationInterceptor. create(Broker broker, ConnectionContext context, ActiveMQDestination destination)
Set
DefaultAuthorizationMap. get(ActiveMQDestination key)
Looks up the value(s) matching the given Destination key.protected Set<GroupPrincipal>
LDAPAuthorizationMap. getACLs(ActiveMQDestination destination, String roleBase, String roleAttribute)
Set<?>
AuthorizationMap. getAdminACLs(ActiveMQDestination destination)
Returns the set of all ACLs capable of administering the given destinationSet<Object>
DefaultAuthorizationMap. getAdminACLs(ActiveMQDestination destination)
Set<GroupPrincipal>
LDAPAuthorizationMap. getAdminACLs(ActiveMQDestination destination)
Set<Object>
SimpleAuthorizationMap. getAdminACLs(ActiveMQDestination destination)
Set<Object>
SimpleCachedLDAPAuthorizationMap. getAdminACLs(ActiveMQDestination destination)
Provides synchronized access to the admin ACLs for the destinations asAuthorizationEntry
is not setup for concurrent access.protected Set<AuthorizationEntry>
DefaultAuthorizationMap. getAllEntries(ActiveMQDestination destination)
protected Set<GroupPrincipal>
LDAPAuthorizationMap. getCompositeACLs(ActiveMQDestination destination, String roleBase, String roleAttribute)
AuthorizationEntry
DefaultAuthorizationMap. getEntryFor(ActiveMQDestination destination)
Set<?>
AuthorizationMap. getReadACLs(ActiveMQDestination destination)
Returns the set of all ACLs capable of reading (consuming from) the given destinationSet<Object>
DefaultAuthorizationMap. getReadACLs(ActiveMQDestination destination)
Set<GroupPrincipal>
LDAPAuthorizationMap. getReadACLs(ActiveMQDestination destination)
Set<Object>
SimpleAuthorizationMap. getReadACLs(ActiveMQDestination destination)
Set<Object>
SimpleCachedLDAPAuthorizationMap. getReadACLs(ActiveMQDestination destination)
Provides synchronized access to the read ACLs for the destinations asAuthorizationEntry
is not setup for concurrent access.Set<?>
AuthorizationMap. getWriteACLs(ActiveMQDestination destination)
Returns the set of all ACLs capable of writing to the given destinationSet<Object>
DefaultAuthorizationMap. getWriteACLs(ActiveMQDestination destination)
Set<GroupPrincipal>
LDAPAuthorizationMap. getWriteACLs(ActiveMQDestination destination)
Set<Object>
SimpleAuthorizationMap. getWriteACLs(ActiveMQDestination destination)
Set<Object>
SimpleCachedLDAPAuthorizationMap. getWriteACLs(ActiveMQDestination destination)
Provides synchronized access to the write ACLs for the destinations asAuthorizationEntry
is not setup for concurrent access.void
AbstractAuthenticationBroker. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
void
AuthorizationBroker. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
void
JaasDualAuthenticationBroker. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
-
Uses of ActiveMQDestination in org.apache.activemq.shiro.authz
Methods in org.apache.activemq.shiro.authz that return ActiveMQDestination Modifier and Type Method Description ActiveMQDestination
DestinationAction. getDestination()
Methods in org.apache.activemq.shiro.authz with parameters of type ActiveMQDestination Modifier and Type Method Description Destination
AuthorizationFilter. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean create)
protected Collection<org.apache.shiro.authz.Permission>
DestinationActionPermissionResolver. createPermissions(ActiveMQDestination dest, String verb)
protected String
DestinationActionPermissionResolver. createPermissionString(ActiveMQDestination dest, String verb)
Inspects the specifieddestination
andverb
and returns aWildcardPermission
-compatible String the represents the action.void
AuthorizationFilter. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
Constructors in org.apache.activemq.shiro.authz with parameters of type ActiveMQDestination Constructor Description DestinationAction(ConnectionContext connectionContext, ActiveMQDestination destination, String verb)
-
Uses of ActiveMQDestination in org.apache.activemq.shiro.subject
Methods in org.apache.activemq.shiro.subject that return types with arguments of type ActiveMQDestination Modifier and Type Method Description ConcurrentMap<ActiveMQDestination,ActiveMQDestination>
SubjectSecurityContext. getAuthorizedWriteDests()
ConcurrentMap<ActiveMQDestination,ActiveMQDestination>
SubjectSecurityContext. getAuthorizedWriteDests()
-
Uses of ActiveMQDestination in org.apache.activemq.state
Methods in org.apache.activemq.state with parameters of type ActiveMQDestination Modifier and Type Method Description void
ConnectionState. removeTempDestination(ActiveMQDestination destination)
-
Uses of ActiveMQDestination in org.apache.activemq.store
Fields in org.apache.activemq.store declared as ActiveMQDestination Modifier and Type Field Description protected ActiveMQDestination
AbstractMessageStore. destination
Methods in org.apache.activemq.store that return ActiveMQDestination Modifier and Type Method Description ActiveMQDestination
AbstractMessageStore. getDestination()
ActiveMQDestination
MessageStore. getDestination()
The destination that the message store is holding messages for.ActiveMQDestination
ProxyMessageStore. getDestination()
ActiveMQDestination
ProxyTopicMessageStore. getDestination()
Methods in org.apache.activemq.store that return types with arguments of type ActiveMQDestination Modifier and Type Method Description Set<ActiveMQDestination>
PersistenceAdapter. getDestinations()
Returns a set of all theActiveMQDestination
objects that the persistence store is aware exist.Methods in org.apache.activemq.store with parameters of type ActiveMQDestination Modifier and Type Method Description boolean
PersistenceAdapterSupport.DestinationMatcher. matches(ActiveMQDestination destination)
Given a Destination object, return true if the destination matches some defined search criteria, false otherwise.Constructors in org.apache.activemq.store with parameters of type ActiveMQDestination Constructor Description AbstractMessageStore(ActiveMQDestination destination)
-
Uses of ActiveMQDestination in org.apache.activemq.store.jdbc
Fields in org.apache.activemq.store.jdbc with type parameters of type ActiveMQDestination Modifier and Type Field Description protected HashMap<ActiveMQDestination,MessageStore>
JDBCPersistenceAdapter. storeCache
Methods in org.apache.activemq.store.jdbc that return types with arguments of type ActiveMQDestination Modifier and Type Method Description Set<ActiveMQDestination>
JDBCAdapter. doGetDestinations(TransactionContext c)
Set<ActiveMQDestination>
JDBCPersistenceAdapter. getDestinations()
Methods in org.apache.activemq.store.jdbc with parameters of type ActiveMQDestination Modifier and Type Method Description void
JDBCPersistenceAdapter. commitLastAck(ConnectionContext context, long xidLastAck, long priority, ActiveMQDestination destination, String subName, String clientId)
void
JDBCAdapter. doAddMessage(TransactionContext c, long sequence, MessageId messageID, ActiveMQDestination destination, byte[] data, long expiration, byte priority, XATransactionId xid)
void
JDBCAdapter. doAddMessageReference(TransactionContext c, long sequence, MessageId messageId, ActiveMQDestination destination, long expirationTime, String messageRef)
void
JDBCAdapter. doClearLastAck(TransactionContext c, ActiveMQDestination destination, byte priority, String subId, String subName)
void
JDBCAdapter. doDeleteSubscription(TransactionContext c, ActiveMQDestination destinationName, String clientId, String subscriptionName)
SubscriptionInfo[]
JDBCAdapter. doGetAllSubscriptions(TransactionContext c, ActiveMQDestination destination)
int
JDBCAdapter. doGetDurableSubscriberMessageCount(TransactionContext c, ActiveMQDestination destination, String clientId, String subscriptionName, boolean isPrioritizeMessages)
long
JDBCAdapter. doGetLastAckedDurableSubscriberMessageId(TransactionContext c, ActiveMQDestination destination, String clientId, String subscriberName)
int
JDBCAdapter. doGetMessageCount(TransactionContext c, ActiveMQDestination destination)
SubscriptionInfo
JDBCAdapter. doGetSubscriberEntry(TransactionContext c, ActiveMQDestination destination, String clientId, String subscriptionName)
void
JDBCAdapter. doRecordDestination(TransactionContext c, ActiveMQDestination destination)
void
JDBCAdapter. doRecover(TransactionContext c, ActiveMQDestination destination, JDBCMessageRecoveryListener listener)
void
JDBCAdapter. doRecoverNextMessages(TransactionContext c, ActiveMQDestination destination, long[] lastRecoveredEntries, long maxSeq, int maxReturned, boolean isPrioritizeMessages, JDBCMessageRecoveryListener listener)
void
JDBCAdapter. doRecoverNextMessages(TransactionContext c, ActiveMQDestination destination, String clientId, String subscriptionName, long seq, long priority, int maxReturned, JDBCMessageRecoveryListener listener)
void
JDBCAdapter. doRecoverNextMessagesWithPriority(TransactionContext c, ActiveMQDestination destination, String clientId, String subscriptionName, long seq, long priority, int maxReturned, JDBCMessageRecoveryListener listener)
void
JDBCAdapter. doRecoverSubscription(TransactionContext c, ActiveMQDestination destination, String clientId, String subscriptionName, JDBCMessageRecoveryListener listener)
void
JDBCAdapter. doRemoveAllMessages(TransactionContext c, ActiveMQDestination destinationName)
void
JDBCAdapter. doSetLastAck(TransactionContext c, ActiveMQDestination destination, XATransactionId xid, String clientId, String subscriptionName, long seq, long prio)
void
JDBCAdapter. doSetLastAckWithPriority(TransactionContext c, ActiveMQDestination destination, XATransactionId xid, String clientId, String subscriptionName, long re, long re1)
void
JDBCAdapter. doUpdateMessage(TransactionContext c, ActiveMQDestination destination, MessageId id, byte[] data)
long[]
JDBCTopicMessageStore. getCachedStoreSequenceId(TransactionContext transactionContext, ActiveMQDestination destination, MessageId messageId)
long[]
JDBCAdapter. getStoreSequenceId(TransactionContext c, ActiveMQDestination destination, MessageId messageID)
void
JdbcMemoryTransactionStore. recoverLastAck(byte[] encodedXid, ActiveMQDestination destination, String subName, String clientId)
void
JDBCPersistenceAdapter. rollbackLastAck(ConnectionContext context, byte priority, ActiveMQDestination destination, String subName, String clientId)
Constructors in org.apache.activemq.store.jdbc with parameters of type ActiveMQDestination Constructor Description JDBCMessageStore(JDBCPersistenceAdapter persistenceAdapter, JDBCAdapter adapter, WireFormat wireFormat, ActiveMQDestination destination, ActiveMQMessageAudit audit)
-
Uses of ActiveMQDestination in org.apache.activemq.store.jdbc.adapter
Methods in org.apache.activemq.store.jdbc.adapter that return types with arguments of type ActiveMQDestination Modifier and Type Method Description Set<ActiveMQDestination>
DefaultJDBCAdapter. doGetDestinations(TransactionContext c)
Methods in org.apache.activemq.store.jdbc.adapter with parameters of type ActiveMQDestination Modifier and Type Method Description void
BlobJDBCAdapter. doAddMessage(TransactionContext c, long sequence, MessageId messageID, ActiveMQDestination destination, byte[] data, long expiration, byte priority, XATransactionId xid)
void
DefaultJDBCAdapter. doAddMessage(TransactionContext c, long sequence, MessageId messageID, ActiveMQDestination destination, byte[] data, long expiration, byte priority, XATransactionId xid)
A non null xid indicated the op is part of 2pc prepare, so ops are flagged pending outcomevoid
DefaultJDBCAdapter. doAddMessageReference(TransactionContext c, long sequence, MessageId messageID, ActiveMQDestination destination, long expirationTime, String messageRef)
void
DefaultJDBCAdapter. doClearLastAck(TransactionContext c, ActiveMQDestination destination, byte priority, String clientId, String subName)
void
DefaultJDBCAdapter. doDeleteSubscription(TransactionContext c, ActiveMQDestination destination, String clientId, String subscriptionName)
SubscriptionInfo[]
DefaultJDBCAdapter. doGetAllSubscriptions(TransactionContext c, ActiveMQDestination destination)
int
DefaultJDBCAdapter. doGetDurableSubscriberMessageCount(TransactionContext c, ActiveMQDestination destination, String clientId, String subscriptionName, boolean isPrioritizedMessages)
long
DefaultJDBCAdapter. doGetLastAckedDurableSubscriberMessageId(TransactionContext c, ActiveMQDestination destination, String clientId, String subscriberName)
int
DefaultJDBCAdapter. doGetMessageCount(TransactionContext c, ActiveMQDestination destination)
SubscriptionInfo
DefaultJDBCAdapter. doGetSubscriberEntry(TransactionContext c, ActiveMQDestination destination, String clientId, String subscriptionName)
void
DefaultJDBCAdapter. doRecordDestination(TransactionContext c, ActiveMQDestination destination)
void
DefaultJDBCAdapter. doRecover(TransactionContext c, ActiveMQDestination destination, JDBCMessageRecoveryListener listener)
void
DefaultJDBCAdapter. doRecoverNextMessages(TransactionContext c, ActiveMQDestination destination, long[] lastRecoveredEntries, long maxSeq, int maxReturned, boolean isPrioritizedMessages, JDBCMessageRecoveryListener listener)
void
DefaultJDBCAdapter. doRecoverNextMessages(TransactionContext c, ActiveMQDestination destination, String clientId, String subscriptionName, long seq, long priority, int maxReturned, JDBCMessageRecoveryListener listener)
void
DefaultJDBCAdapter. doRecoverNextMessagesWithPriority(TransactionContext c, ActiveMQDestination destination, String clientId, String subscriptionName, long seq, long priority, int maxReturned, JDBCMessageRecoveryListener listener)
void
DefaultJDBCAdapter. doRecoverSubscription(TransactionContext c, ActiveMQDestination destination, String clientId, String subscriptionName, JDBCMessageRecoveryListener listener)
void
DefaultJDBCAdapter. doRemoveAllMessages(TransactionContext c, ActiveMQDestination destinationName)
void
DefaultJDBCAdapter. doSetLastAck(TransactionContext c, ActiveMQDestination destination, XATransactionId xid, String clientId, String subscriptionName, long seq, long priority)
void
DefaultJDBCAdapter. doSetLastAckWithPriority(TransactionContext c, ActiveMQDestination destination, XATransactionId xid, String clientId, String subscriptionName, long seq, long priority)
void
DefaultJDBCAdapter. doUpdateMessage(TransactionContext c, ActiveMQDestination destination, MessageId id, byte[] data)
long[]
DefaultJDBCAdapter. getStoreSequenceId(TransactionContext c, ActiveMQDestination destination, MessageId messageID)
-
Uses of ActiveMQDestination in org.apache.activemq.store.journal
Methods in org.apache.activemq.store.journal that return types with arguments of type ActiveMQDestination Modifier and Type Method Description Set<ActiveMQDestination>
JournalPersistenceAdapter. getDestinations()
Constructors in org.apache.activemq.store.journal with parameters of type ActiveMQDestination Constructor Description JournalMessageStore(JournalPersistenceAdapter adapter, MessageStore checkpointStore, ActiveMQDestination destination)
-
Uses of ActiveMQDestination in org.apache.activemq.store.kahadb
Methods in org.apache.activemq.store.kahadb that return ActiveMQDestination Modifier and Type Method Description ActiveMQDestination
KahaDBStore.KahaDBMessageStore. getDestination()
ActiveMQDestination
TempKahaDBStore.KahaDBMessageStore. getDestination()
Methods in org.apache.activemq.store.kahadb that return types with arguments of type ActiveMQDestination Modifier and Type Method Description Set<ActiveMQDestination>
KahaDBPersistenceAdapter. getDestinations()
Set<ActiveMQDestination>
KahaDBStore. getDestinations()
Set<ActiveMQDestination>
MultiKahaDBPersistenceAdapter. getDestinations()
Set<ActiveMQDestination>
TempKahaDBStore. getDestinations()
Methods in org.apache.activemq.store.kahadb with parameters of type ActiveMQDestination Modifier and Type Method Description static String
MultiKahaDBPersistenceAdapter. nameFromDestinationFilter(ActiveMQDestination destination)
Constructors in org.apache.activemq.store.kahadb with parameters of type ActiveMQDestination Constructor Description FilteredKahaDBPersistenceAdapter(FilteredKahaDBPersistenceAdapter template, ActiveMQDestination destination, PersistenceAdapter adapter)
KahaDBMessageStore(ActiveMQDestination destination)
KahaDBMessageStore(ActiveMQDestination destination)
-
Uses of ActiveMQDestination in org.apache.activemq.store.memory
Methods in org.apache.activemq.store.memory that return types with arguments of type ActiveMQDestination Modifier and Type Method Description Set<ActiveMQDestination>
MemoryPersistenceAdapter. getDestinations()
Constructors in org.apache.activemq.store.memory with parameters of type ActiveMQDestination Constructor Description MemoryMessageStore(ActiveMQDestination destination)
MemoryMessageStore(ActiveMQDestination destination, Map<MessageId,Message> messageTable)
MemoryTopicMessageStore(ActiveMQDestination destination)
MemoryTopicMessageStore(ActiveMQDestination destination, Map<MessageId,Message> messageTable, Map<SubscriptionKey,SubscriptionInfo> subscriberDatabase)
-
Uses of ActiveMQDestination in org.apache.activemq.transport.amqp
Methods in org.apache.activemq.transport.amqp that return ActiveMQDestination Modifier and Type Method Description static ActiveMQDestination
AmqpSupport. createDestination(Object endpoint)
Given an AMQP endpoint, deduce the appropriate ActiveMQDestination type and create a new instance.Methods in org.apache.activemq.transport.amqp with parameters of type ActiveMQDestination Modifier and Type Method Description static org.apache.qpid.proton.amqp.Symbol
AmqpSupport. getDestinationTypeSymbol(ActiveMQDestination destination)
Given an ActiveMQDestination return the proper Capability value for the concrete destination type. -
Uses of ActiveMQDestination in org.apache.activemq.transport.amqp.protocol
Methods in org.apache.activemq.transport.amqp.protocol that return ActiveMQDestination Modifier and Type Method Description ActiveMQDestination
AmqpLink. getDestination()
ActiveMQDestination
AmqpReceiver. getDestination()
ActiveMQDestination
AmqpSender. getDestination()
ActiveMQDestination
AmqpTransactionCoordinator. getDestination()
Methods in org.apache.activemq.transport.amqp.protocol with parameters of type ActiveMQDestination Modifier and Type Method Description void
AmqpLink. setDestination(ActiveMQDestination destination)
Sets the ActiveMQDestination that this link will be servicing.void
AmqpReceiver. setDestination(ActiveMQDestination destination)
void
AmqpSender. setDestination(ActiveMQDestination destination)
void
AmqpTransactionCoordinator. setDestination(ActiveMQDestination destination)
-
Uses of ActiveMQDestination in org.apache.activemq.transport.mqtt
Methods in org.apache.activemq.transport.mqtt that return ActiveMQDestination Modifier and Type Method Description ActiveMQDestination
MQTTSubscription. getDestination()
The realActiveMQDestination
that this subscription is assigned. -
Uses of ActiveMQDestination in org.apache.activemq.transport.mqtt.strategy
Methods in org.apache.activemq.transport.mqtt.strategy that return ActiveMQDestination Modifier and Type Method Description ActiveMQDestination
AbstractMQTTSubscriptionStrategy. onSend(String topicName)
ActiveMQDestination
MQTTSubscriptionStrategy. onSend(String topicName)
Intercepts PUBLISH operations from the client and allows the strategy to map the target destination so that the send operation will land in the destinations that this strategy has mapped the incoming subscribe requests to.ActiveMQDestination
MQTTVirtualTopicSubscriptionStrategy. onSend(String topicName)
Methods in org.apache.activemq.transport.mqtt.strategy with parameters of type ActiveMQDestination Modifier and Type Method Description boolean
AbstractMQTTSubscriptionStrategy. isControlTopic(ActiveMQDestination destination)
boolean
MQTTSubscriptionStrategy. isControlTopic(ActiveMQDestination destination)
Allows the protocol handler to interrogate an destination name to determine if it is equivalent to the MQTT control topic (starts with $).boolean
MQTTVirtualTopicSubscriptionStrategy. isControlTopic(ActiveMQDestination destination)
String
AbstractMQTTSubscriptionStrategy. onSend(ActiveMQDestination destination)
String
MQTTSubscriptionStrategy. onSend(ActiveMQDestination destination)
Intercepts send operations from the broker and allows the strategy to map the target topic name so that the client sees a valid Topic name.String
MQTTVirtualTopicSubscriptionStrategy. onSend(ActiveMQDestination destination)
-
Uses of ActiveMQDestination in org.apache.activemq.transport.stomp
Fields in org.apache.activemq.transport.stomp declared as ActiveMQDestination Modifier and Type Field Description protected ActiveMQDestination
StompSubscription. destination
Methods in org.apache.activemq.transport.stomp that return ActiveMQDestination Modifier and Type Method Description ActiveMQDestination
FrameTranslator. convertDestination(ProtocolConverter converter, String name, boolean forceFallback)
ActiveMQDestination
LegacyFrameTranslator. convertDestination(ProtocolConverter converter, String name, boolean forceFallback)
ActiveMQDestination
ProtocolConverter. createTempDestination(String name, boolean topic)
ActiveMQDestination
StompSubscription. getDestination()
Methods in org.apache.activemq.transport.stomp with parameters of type ActiveMQDestination Modifier and Type Method Description protected FrameTranslator
ProtocolConverter. findTranslator(String header, ActiveMQDestination destination, boolean advisory)
String
ProtocolConverter. getCreatedTempDestinationName(ActiveMQDestination destination)
void
StompSubscription. setDestination(ActiveMQDestination destination)
-
Uses of ActiveMQDestination in org.apache.activemq.util
Methods in org.apache.activemq.util that return ActiveMQDestination Modifier and Type Method Description static ActiveMQDestination
NetworkBridgeUtils. findMatchingDestination(ActiveMQDestination[] dests, ActiveMQDestination destination)
Methods in org.apache.activemq.util that return types with arguments of type ActiveMQDestination Modifier and Type Method Description static List<ActiveMQDestination>
StringToListOfActiveMQDestinationConverter. convertToActiveMQDestination(Object value)
Methods in org.apache.activemq.util with parameters of type ActiveMQDestination Modifier and Type Method Description static void
BrokerSupport. doResend(ConnectionContext context, Message originalMessage, ActiveMQDestination deadLetterDestination, boolean copy)
static ActiveMQDestination
NetworkBridgeUtils. findMatchingDestination(ActiveMQDestination[] dests, ActiveMQDestination destination)
static boolean
NetworkBridgeUtils. isDestForcedDurable(ActiveMQDestination destination)
static boolean
NetworkBridgeUtils. isForcedDurable(ConsumerInfo info, ActiveMQDestination[] dynamicallyIncludedDestinations, ActiveMQDestination[] staticallyIncludedDestinations)
static boolean
NetworkBridgeUtils. matchesDestinations(ActiveMQDestination[] dests, ActiveMQDestination destination)
static boolean
NetworkBridgeUtils. matchesNetworkConfig(NetworkBridgeConfiguration config, ActiveMQDestination destination)
static void
BrokerSupport. resend(ConnectionContext context, Message originalMessage, ActiveMQDestination deadLetterDestination)
static void
BrokerSupport. resendNoCopy(ConnectionContext context, Message originalMessage, ActiveMQDestination deadLetterDestination)
Method parameters in org.apache.activemq.util with type arguments of type ActiveMQDestination Modifier and Type Method Description static boolean
NetworkBridgeUtils. isForcedDurable(ConsumerInfo info, List<ActiveMQDestination> dynamicallyIncludedDestinations)
-
Uses of ActiveMQDestination in org.apache.activemq.web
Methods in org.apache.activemq.web that return ActiveMQDestination Modifier and Type Method Description protected ActiveMQDestination
DestinationFacade. createDestination()
Methods in org.apache.activemq.web with parameters of type ActiveMQDestination Modifier and Type Method Description void
BrokerFacade. purgeQueue(ActiveMQDestination destination)
Purges the given destinationvoid
LocalBrokerFacade. purgeQueue(ActiveMQDestination destination)
void
RemoteJMXBrokerFacade. purgeQueue(ActiveMQDestination destination)
-
Uses of ActiveMQDestination in org.apache.activemq.web.controller
Methods in org.apache.activemq.web.controller with parameters of type ActiveMQDestination Modifier and Type Method Description protected void
SendMessage. sendMessages(HttpServletRequest request, WebClient client, ActiveMQDestination dest)
-