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 ActiveMQDestinationActiveMQMessageConsumer. getDestination()static ActiveMQDestinationActiveMQMessageTransformation. 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 voidActiveMQConnection. destroyDestination(ActiveMQDestination destination)booleanActiveMQConnection. isDeleted(ActiveMQDestination dest)protected voidActiveMQSession. 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. destinationsMethods in org.apache.activemq.advisory that return ActiveMQDestination Modifier and Type Method Description ActiveMQDestinationDestinationEvent. 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 DestinationBrokerBroadcaster. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean createIfTemporary)DestinationBrokerFilter. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean createIfTemporary)DestinationEmptyBroker. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean flag)DestinationErrorBroker. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean flag)voidBroker. fastProducer(ConnectionContext context, ProducerInfo producerInfo, ActiveMQDestination destination)Called to notify a producer is too fastvoidBrokerFilter. fastProducer(ConnectionContext context, ProducerInfo producerInfo, ActiveMQDestination destination)voidEmptyBroker. fastProducer(ConnectionContext context, ProducerInfo producerInfo, ActiveMQDestination destination)voidErrorBroker. fastProducer(ConnectionContext context, ProducerInfo producerInfo, ActiveMQDestination destination)DestinationBrokerService. 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)voidBrokerBroadcaster. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)voidBrokerFilter. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)voidBrokerService. removeDestination(ActiveMQDestination destination)voidEmptyBroker. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)voidErrorBroker. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)voidBrokerService. setDestinations(ActiveMQDestination[] destinations)Sets the destinations which should be loaded/created on startupbooleanBrokerService. shouldRecordVirtualDestination(ActiveMQDestination destination)Method parameters in org.apache.activemq.broker with type arguments of type ActiveMQDestination Modifier and Type Method Description voidBrokerService. 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 MessageInterceptorMessageInterceptorRegistry. addMessageInterceptor(ActiveMQDestination activeMQDestination, MessageInterceptor messageInterceptor)voidMessageInterceptorRegistry. 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 ActiveMQDestinationProducerView. lastUsedDestinationMethods in org.apache.activemq.broker.jmx with parameters of type ActiveMQDestination Modifier and Type Method Description protected DestinationManagedQueueRegion. createDestination(ConnectionContext context, ActiveMQDestination destination)protected DestinationManagedTempQueueRegion. createDestination(ConnectionContext context, ActiveMQDestination destination)protected DestinationManagedTempTopicRegion. createDestination(ConnectionContext context, ActiveMQDestination destination)protected DestinationManagedTopicRegion. createDestination(ConnectionContext context, ActiveMQDestination destination)static ObjectNameBrokerMBeanSupport. createDestinationName(String brokerObjectName, ActiveMQDestination destination)static ObjectNameBrokerMBeanSupport. createDestinationName(ObjectName brokerObjectName, ActiveMQDestination destination)static ObjectNameBrokerMBeanSupport. createNetworkInBoundDestinationObjectName(ObjectName networkName, ActiveMQDestination destination)static ObjectNameBrokerMBeanSupport. createNetworkOutBoundDestinationObjectName(ObjectName networkName, ActiveMQDestination destination)booleanSubscriptionView. matchesDestination(ActiveMQDestination destination)Return true if this subscription matches the given destinationvoidManagedRegionBroker. register(ActiveMQDestination destName, Destination destination)protected voidManagedRegionBroker. registerDestination(ObjectName key, ActiveMQDestination dest, DestinationView view)protected voidManagedRegionBroker. registerProducer(ObjectName key, ActiveMQDestination dest, ProducerView view)voidManagedQueueRegion. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)voidManagedTempQueueRegion. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)voidManagedTempTopicRegion. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)voidManagedTopicRegion. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)voidManagedRegionBroker. 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 ActiveMQDestinationBaseDestination. destinationFields in org.apache.activemq.broker.region with type parameters of type ActiveMQDestination Modifier and Type Field Description protected Map<ActiveMQDestination,Destination>AbstractRegion. destinationsMethods in org.apache.activemq.broker.region that return ActiveMQDestination Modifier and Type Method Description ActiveMQDestinationAbstractSubscription. getActiveMQDestination()ActiveMQDestinationBaseDestination. getActiveMQDestination()ActiveMQDestinationDestination. getActiveMQDestination()ActiveMQDestinationDestinationFilter. getActiveMQDestination()ActiveMQDestinationQueue. getActiveMQDestination()ActiveMQDestinationSubscriptionRecovery. getActiveMQDestination()ActiveMQDestination[]RegionBroker. getDestinations()Methods in org.apache.activemq.broker.region with parameters of type ActiveMQDestination Modifier and Type Method Description DestinationAbstractRegion. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean createIfTemporary)DestinationRegion. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean createIfTemporary)Used to create a destination.DestinationRegionBroker. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean createIfTemp)protected voidDestinationFactoryImpl. configureQueue(Queue queue, ActiveMQDestination destination)protected voidDestinationFactoryImpl. configureTopic(Topic topic, ActiveMQDestination destination)protected voidTopicRegion. configureTopic(Topic topic, ActiveMQDestination destination)intQueue. copyMatchingMessages(ConnectionContext context, MessageReferenceFilter filter, ActiveMQDestination dest, int maximumMessages)Copies the messages matching the given filter up to the maximum number of matched messagesintQueue. copyMatchingMessagesTo(ConnectionContext context, String selector, ActiveMQDestination dest)Copies the messages matching the given selectorintQueue. copyMatchingMessagesTo(ConnectionContext context, String selector, ActiveMQDestination dest, int maximumMessages)Copies the messages matching the given selector up to the maximum number of matched messagesbooleanQueue. copyMessageTo(ConnectionContext context, String messageId, ActiveMQDestination dest)Copies the message matching the given messageIdvoidCompositeDestinationInterceptor. create(Broker broker, ConnectionContext context, ActiveMQDestination destination)voidDestinationInterceptor. create(Broker broker, ConnectionContext context, ActiveMQDestination destination)protected DestinationAbstractRegion. createDestination(ConnectionContext context, ActiveMQDestination destination)protected DestinationAbstractTempRegion. createDestination(ConnectionContext context, ActiveMQDestination destination)abstract DestinationDestinationFactory. createDestination(ConnectionContext context, ActiveMQDestination destination, DestinationStatistics destinationStatistics)Create destination implementation.DestinationDestinationFactoryImpl. createDestination(ConnectionContext context, ActiveMQDestination destination, DestinationStatistics destinationStatistics)protected JMSExceptionRegionBroker. 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)RegionRegionBroker. getRegion(ActiveMQDestination destination)protected DestinationAbstractRegion. lookup(ConnectionContext context, ActiveMQDestination destination, boolean createTemporary)booleanAbstractSubscription. matches(ActiveMQDestination destination)booleanSubscription. matches(ActiveMQDestination destination)Is the subscription interested in messages in the destination?intQueue. moveMatchingMessagesTo(ConnectionContext context, String selector, ActiveMQDestination dest)Moves the messages matching the given selectorintQueue. moveMatchingMessagesTo(ConnectionContext context, String selector, ActiveMQDestination dest, int maximumMessages)Moves the messages matching the given selector up to the maximum number of matched messagesintQueue. moveMatchingMessagesTo(ConnectionContext context, MessageReferenceFilter filter, ActiveMQDestination dest, int maximumMessages)Moves the messages matching the given filter up to the maximum number of matched messagesbooleanQueue. moveMessageTo(ConnectionContext context, String messageId, ActiveMQDestination dest)Moves the message matching the given messageIdbooleanQueue. moveMessageTo(ConnectionContext context, QueueMessageReference m, ActiveMQDestination dest)Move a messagevoidAbstractRegion. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)voidRegion. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)Used to destroy a destination.voidRegionBroker. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)voidTempQueueRegion. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)voidTempTopicRegion. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)protected voidDestinationFilter. send(ProducerBrokerExchange context, Message message, ActiveMQDestination destination)Sends a message to the given destination which may be a wildcardprotected voidAbstractRegion. updateRegionDestCounts(ActiveMQDestination destination, int count)Updates the counts in RegionStatistics based on whether or not the destination is an Advisory Destination or notprotected voidAbstractRegion. 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 ActiveMQDestinationIndividualDeadLetterStrategy. createDestination(Message message, String prefix, String suffix, boolean useQueue, Subscription subscription)ActiveMQDestinationSharedDeadLetterStrategy. getDeadLetterQueue()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)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)voidMessageQuery. execute(ActiveMQDestination destination, MessageListener listener)Executes the query for messages; each message is passed into the listenerPolicyEntryPolicyMap. getEntryFor(ActiveMQDestination destination)RedeliveryPolicyRedeliveryPolicyMap. getEntryFor(ActiveMQDestination destination)voidSharedDeadLetterStrategy. 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 ActiveMQDestinationFilteredDestination. getDestination()ActiveMQDestinationCompositeDestination. getMappedDestinations()ActiveMQDestinationVirtualDestination. getMappedDestinations()Returns mapped destination(s)ActiveMQDestinationVirtualTopic. getMappedDestinations()protected ActiveMQDestinationMirroredQueue. getMirrorTopic(ActiveMQDestination original)protected ActiveMQDestinationVirtualTopicInterceptor. getQueueConsumersWildcard(ActiveMQDestination original)ActiveMQDestinationCompositeQueue. getVirtualDestination()ActiveMQDestinationCompositeTopic. getVirtualDestination()ActiveMQDestinationVirtualDestination. getVirtualDestination()Returns the virtual destinationActiveMQDestinationVirtualTopic. getVirtualDestination()Methods in org.apache.activemq.broker.region.virtual with parameters of type ActiveMQDestination Modifier and Type Method Description voidCompositeDestination. create(Broker broker, ConnectionContext context, ActiveMQDestination destination)voidMirroredQueue. create(Broker broker, ConnectionContext context, ActiveMQDestination destination)voidVirtualDestinationInterceptor. create(Broker broker, ConnectionContext context, ActiveMQDestination destination)voidVirtualTopic. create(Broker broker, ConnectionContext context, ActiveMQDestination destination)protected ActiveMQDestinationMirroredQueue. getMirrorTopic(ActiveMQDestination original)protected ActiveMQDestinationVirtualTopicInterceptor. getQueueConsumersWildcard(ActiveMQDestination original)protected voidVirtualTopicInterceptor. send(ProducerBrokerExchange context, Message message, ActiveMQDestination destination)voidFilteredDestination. 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 voidSchedulerBroker. 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 ActiveMQDestinationDestinationPathSeparatorBroker. 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 DestinationDestinationPathSeparatorBroker. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean createIfTemporary)DestinationDestinationsPlugin. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean createIfTemporary)DestinationLoggingBrokerPlugin. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean create)protected ActiveMQDestinationDestinationPathSeparatorBroker. convertDestination(ActiveMQDestination destination)voidLoggingBrokerPlugin. fastProducer(ConnectionContext context, ProducerInfo producerInfo, ActiveMQDestination destination)voidDestinationPathSeparatorBroker. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)voidDestinationsPlugin. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)voidLoggingBrokerPlugin. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)voidUDPTraceBrokerPlugin. 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 DestinationDestinationDotFileInterceptor. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean create)BrokerDestinationViewMessageBrokerView. getDestinationView(ActiveMQDestination activeMQDestination)Get the BrokerDestinationView associated with destinationvoidDestinationDotFileInterceptor. 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 classActiveMQQueueclassActiveMQTempDestinationclassActiveMQTempQueueclassActiveMQTempTopicclassActiveMQTopicFields in org.apache.activemq.command declared as ActiveMQDestination Modifier and Type Field Description protected ActiveMQDestination[]ActiveMQDestination. compositeDestinationsprotected ActiveMQDestinationConsumerControl. destinationprotected ActiveMQDestinationConsumerInfo. destinationprotected ActiveMQDestinationDestinationInfo. destinationprotected ActiveMQDestinationMessage. destinationprotected ActiveMQDestinationMessageAck. destinationprotected ActiveMQDestinationMessageDispatch. destinationprotected ActiveMQDestinationMessageDispatchNotification. destinationprotected ActiveMQDestinationMessagePull. destinationprotected ActiveMQDestinationProducerInfo. destinationprotected ActiveMQDestinationSubscriptionInfo. destinationprotected ActiveMQDestinationMessage. originalDestinationprotected ActiveMQDestinationMessage. replyToprotected ActiveMQDestinationSubscriptionInfo. subscribedDestinationMethods in org.apache.activemq.command that return ActiveMQDestination Modifier and Type Method Description ActiveMQDestinationActiveMQDestination. createDestination(String name)static ActiveMQDestinationActiveMQDestination. createDestination(String name, byte defaultType)ActiveMQDestination[]ActiveMQDestination. getCompositeDestinations()ActiveMQDestinationConsumerControl. getDestination()ActiveMQDestinationConsumerInfo. getDestination()The destination that the consumer is interested in receiving messages from.ActiveMQDestinationDestinationInfo. getDestination()ActiveMQDestinationJournalQueueAck. getDestination()ActiveMQDestinationJournalTopicAck. getDestination()ActiveMQDestinationMessage. getDestination()ActiveMQDestinationMessageAck. getDestination()ActiveMQDestinationMessageDispatch. getDestination()ActiveMQDestinationMessageDispatchNotification. getDestination()ActiveMQDestinationMessagePull. getDestination()ActiveMQDestinationProducerInfo. getDestination()ActiveMQDestinationSubscriptionInfo. getDestination()This is the a resolved destination that the subscription is receiving messages from.ActiveMQDestinationMessage. getOriginalDestination()ActiveMQDestinationMessage. getReplyTo()ActiveMQDestinationSubscriptionInfo. getSubscribedDestination()The destination the client originally subscribed to..static ActiveMQDestinationActiveMQDestination. transform(Destination dest)ActiveMQDestinationDefaultUnresolvedDestinationTransformer. transform(String dest)ActiveMQDestinationDefaultUnresolvedDestinationTransformer. transform(Destination dest)ActiveMQDestinationUnresolvedDestinationTransformer. transform(String dest)ActiveMQDestinationUnresolvedDestinationTransformer. transform(Destination dest)Methods in org.apache.activemq.command with parameters of type ActiveMQDestination Modifier and Type Method Description voidConsumerInfo. clearAssignedGroupCount(ActiveMQDestination dest)static intActiveMQDestination. compare(ActiveMQDestination destination, ActiveMQDestination destination2)voidConsumerInfo. decrementAssignedGroupCount(ActiveMQDestination dest)longConsumerInfo. getAssignedGroupCount(ActiveMQDestination dest)voidConsumerInfo. incrementAssignedGroupCount(ActiveMQDestination dest)voidActiveMQDestination. setCompositeDestinations(ActiveMQDestination[] destinations)voidConsumerControl. setDestination(ActiveMQDestination destination)voidConsumerInfo. setDestination(ActiveMQDestination destination)voidDestinationInfo. setDestination(ActiveMQDestination destination)voidJournalQueueAck. setDestination(ActiveMQDestination destination)voidJournalTopicAck. setDestination(ActiveMQDestination destination)voidMessage. setDestination(ActiveMQDestination destination)voidMessageAck. setDestination(ActiveMQDestination destination)voidMessageDispatch. setDestination(ActiveMQDestination destination)voidMessageDispatchNotification. setDestination(ActiveMQDestination destination)voidMessagePull. setDestination(ActiveMQDestination destination)voidProducerInfo. setDestination(ActiveMQDestination destination)voidSubscriptionInfo. setDestination(ActiveMQDestination destination)voidMessage. setOriginalDestination(ActiveMQDestination destination)voidMessage. setReplyTo(ActiveMQDestination replyTo)voidSubscriptionInfo. 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 classAnyDestinationFields in org.apache.activemq.filter declared as ActiveMQDestination Modifier and Type Field Description protected ActiveMQDestinationDestinationMapEntry. destinationprotected ActiveMQDestinationMessageEvaluationContext. destinationMethods in org.apache.activemq.filter that return ActiveMQDestination Modifier and Type Method Description ActiveMQDestinationDestinationMapEntry. getDestination()ActiveMQDestinationMessageEvaluationContext. getDestination()Methods in org.apache.activemq.filter with parameters of type ActiveMQDestination Modifier and Type Method Description DestinationMapEntryDestinationMap. chooseValue(ActiveMQDestination destination)Returns the value which matches the given destination or null if there is no matching value.protected SetDestinationMap. findWildcardMatches(ActiveMQDestination key)protected SetDestinationMap. findWildcardMatches(ActiveMQDestination key, boolean deep)SetDestinationMap. get(ActiveMQDestination key)Looks up the value(s) matching the given Destination key.static String[]DestinationPath. getDestinationPaths(ActiveMQDestination destination)protected DestinationMapNodeDestinationMap. getRootNode(ActiveMQDestination key)Returns the root node for the given destination typebooleanCompositeDestinationFilter. matches(ActiveMQDestination destination)abstract booleanDestinationFilter. matches(ActiveMQDestination destination)booleanPrefixDestinationFilter. matches(ActiveMQDestination destination)booleanSimpleDestinationFilter. matches(ActiveMQDestination destination)booleanWildcardDestinationFilter. matches(ActiveMQDestination destination)static DestinationFilterDestinationFilter. parseFilter(ActiveMQDestination destination)voidDestinationMap. put(ActiveMQDestination key, Object value)voidDestinationMap. remove(ActiveMQDestination key, Object value)Removes the value from the associated destinationSetDestinationMap. removeAll(ActiveMQDestination key)voidDestinationMapEntry. setDestination(ActiveMQDestination destination)voidMessageEvaluationContext. setDestination(ActiveMQDestination destination)SetDestinationMap. unsynchronizedGet(ActiveMQDestination key)voidDestinationMap. unsynchronizedPut(ActiveMQDestination key, Object value)voidDestinationMap. 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 ActiveMQDestinationAbstractActiveMQClientResource. 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)ListMessageList. 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. durableDestinationsprotected ActiveMQDestination[]DemandForwardingBridgeSupport. dynamicallyIncludedDestinationsprotected ActiveMQDestination[]DemandForwardingBridgeSupport. excludedDestinationsprotected ActiveMQDestination[]DemandForwardingBridgeSupport. staticallyIncludedDestinationsFields in org.apache.activemq.network with type parameters of type ActiveMQDestination Modifier and Type Field Description protected List<ActiveMQDestination>NetworkBridgeConfiguration. dynamicallyIncludedDestinationsprotected List<ActiveMQDestination>NetworkBridgeConfiguration. excludedDestinationsprotected List<ActiveMQDestination>NetworkBridgeConfiguration. staticallyIncludedDestinationsMethods 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 voidNetworkConnector. addDynamicallyIncludedDestination(ActiveMQDestination destination)voidNetworkConnector. addExcludedDestination(ActiveMQDestination destination)voidNetworkConnector. addStaticallyIncludedDestination(ActiveMQDestination destination)protected DemandSubscriptionDemandForwardingBridgeSupport. createDemandSubscription(ActiveMQDestination destination, String subscriptionName)protected booleanDurableConduitBridge. doesConsumerExist(ActiveMQDestination dest)protected Collection<Subscription>DemandForwardingBridgeSupport. getRegionSubscriptions(ActiveMQDestination dest)protected StringDurableConduitBridge. getSubscriberName(ActiveMQDestination dest)protected booleanDemandForwardingBridgeSupport. isPermissableDestination(ActiveMQDestination destination)protected booleanDemandForwardingBridgeSupport. isPermissableDestination(ActiveMQDestination destination, boolean allowTemporary)voidDemandForwardingBridgeSupport. setDurableDestinations(ActiveMQDestination[] durableDestinations)voidDemandForwardingBridgeSupport. setDynamicallyIncludedDestinations(ActiveMQDestination[] dynamicallyIncludedDestinations)voidDemandForwardingBridgeSupport. setExcludedDestinations(ActiveMQDestination[] excludedDestinations)voidDemandForwardingBridgeSupport. 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)voidNetworkConnector. setDurableDestinations(Set<ActiveMQDestination> durableDestinations)voidNetworkBridgeConfiguration. setDynamicallyIncludedDestinations(List<ActiveMQDestination> dynamicallyIncludedDestinations)voidNetworkBridgeConfiguration. setExcludedDestinations(List<ActiveMQDestination> excludedDestinations)voidNetworkBridgeConfiguration. 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 TargetPartitionBroker. 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 DestinationAbstractRuntimeConfigurationBroker. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean createIfTemporary)protected booleanDestinationsProcessor. containsDestination(ActiveMQDestination destination)protected voidStatisticsBroker. sendStats(ConnectionContext context, ActiveMQMapMessage msg, ActiveMQDestination replyTo)protected voidStatisticsBroker. 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 voidJavaRuntimeConfigurationBroker. addNewDestination(ActiveMQDestination destination)protected booleanJavaRuntimeConfigurationBroker. containsDestination(ActiveMQDestination destination)voidJavaRuntimeConfigurationBroker. 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 ActiveMQDestinationActiveMQActivationSpec. createDestination()Methods in org.apache.activemq.ra with parameters of type ActiveMQDestination Modifier and Type Method Description voidActiveMQActivationSpec. 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. entriesMethods in org.apache.activemq.security that return ActiveMQDestination Modifier and Type Method Description protected ActiveMQDestinationSimpleCachedLDAPAuthorizationMap. formatDestination(LdapName dn, SimpleCachedLDAPAuthorizationMap.DestinationType destinationType)Parses a DN into the equivalentActiveMQDestination.protected ActiveMQDestinationSimpleCachedLDAPAuthorizationMap. 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 DestinationAuthorizationBroker. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean create)protected booleanAuthorizationBroker. checkDestinationAdmin(SecurityContext securityContext, ActiveMQDestination destination)voidAuthorizationDestinationInterceptor. create(Broker broker, ConnectionContext context, ActiveMQDestination destination)SetDefaultAuthorizationMap. 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 asAuthorizationEntryis not setup for concurrent access.protected Set<AuthorizationEntry>DefaultAuthorizationMap. getAllEntries(ActiveMQDestination destination)protected Set<GroupPrincipal>LDAPAuthorizationMap. getCompositeACLs(ActiveMQDestination destination, String roleBase, String roleAttribute)AuthorizationEntryDefaultAuthorizationMap. 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 asAuthorizationEntryis 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 asAuthorizationEntryis not setup for concurrent access.voidAbstractAuthenticationBroker. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)voidAuthorizationBroker. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)voidJaasDualAuthenticationBroker. 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 ActiveMQDestinationDestinationAction. getDestination()Methods in org.apache.activemq.shiro.authz with parameters of type ActiveMQDestination Modifier and Type Method Description DestinationAuthorizationFilter. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean create)protected Collection<org.apache.shiro.authz.Permission>DestinationActionPermissionResolver. createPermissions(ActiveMQDestination dest, String verb)protected StringDestinationActionPermissionResolver. createPermissionString(ActiveMQDestination dest, String verb)Inspects the specifieddestinationandverband returns aWildcardPermission-compatible String the represents the action.voidAuthorizationFilter. 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 voidConnectionState. 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 ActiveMQDestinationAbstractMessageStore. destinationMethods in org.apache.activemq.store that return ActiveMQDestination Modifier and Type Method Description ActiveMQDestinationAbstractMessageStore. getDestination()ActiveMQDestinationMessageStore. getDestination()The destination that the message store is holding messages for.ActiveMQDestinationProxyMessageStore. getDestination()ActiveMQDestinationProxyTopicMessageStore. 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 theActiveMQDestinationobjects that the persistence store is aware exist.Methods in org.apache.activemq.store with parameters of type ActiveMQDestination Modifier and Type Method Description booleanPersistenceAdapterSupport.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. storeCacheMethods 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 voidJDBCPersistenceAdapter. commitLastAck(ConnectionContext context, long xidLastAck, long priority, ActiveMQDestination destination, String subName, String clientId)voidJDBCAdapter. doAddMessage(TransactionContext c, long sequence, MessageId messageID, ActiveMQDestination destination, byte[] data, long expiration, byte priority, XATransactionId xid)voidJDBCAdapter. doAddMessageReference(TransactionContext c, long sequence, MessageId messageId, ActiveMQDestination destination, long expirationTime, String messageRef)voidJDBCAdapter. doClearLastAck(TransactionContext c, ActiveMQDestination destination, byte priority, String subId, String subName)voidJDBCAdapter. doDeleteSubscription(TransactionContext c, ActiveMQDestination destinationName, String clientId, String subscriptionName)SubscriptionInfo[]JDBCAdapter. doGetAllSubscriptions(TransactionContext c, ActiveMQDestination destination)intJDBCAdapter. doGetDurableSubscriberMessageCount(TransactionContext c, ActiveMQDestination destination, String clientId, String subscriptionName, boolean isPrioritizeMessages)longJDBCAdapter. doGetLastAckedDurableSubscriberMessageId(TransactionContext c, ActiveMQDestination destination, String clientId, String subscriberName)intJDBCAdapter. doGetMessageCount(TransactionContext c, ActiveMQDestination destination)SubscriptionInfoJDBCAdapter. doGetSubscriberEntry(TransactionContext c, ActiveMQDestination destination, String clientId, String subscriptionName)voidJDBCAdapter. doRecordDestination(TransactionContext c, ActiveMQDestination destination)voidJDBCAdapter. doRecover(TransactionContext c, ActiveMQDestination destination, JDBCMessageRecoveryListener listener)voidJDBCAdapter. doRecoverNextMessages(TransactionContext c, ActiveMQDestination destination, long[] lastRecoveredEntries, long maxSeq, int maxReturned, boolean isPrioritizeMessages, JDBCMessageRecoveryListener listener)voidJDBCAdapter. doRecoverNextMessages(TransactionContext c, ActiveMQDestination destination, String clientId, String subscriptionName, long seq, long priority, int maxReturned, JDBCMessageRecoveryListener listener)voidJDBCAdapter. doRecoverNextMessagesWithPriority(TransactionContext c, ActiveMQDestination destination, String clientId, String subscriptionName, long seq, long priority, int maxReturned, JDBCMessageRecoveryListener listener)voidJDBCAdapter. doRecoverSubscription(TransactionContext c, ActiveMQDestination destination, String clientId, String subscriptionName, JDBCMessageRecoveryListener listener)voidJDBCAdapter. doRemoveAllMessages(TransactionContext c, ActiveMQDestination destinationName)voidJDBCAdapter. doSetLastAck(TransactionContext c, ActiveMQDestination destination, XATransactionId xid, String clientId, String subscriptionName, long seq, long prio)voidJDBCAdapter. doSetLastAckWithPriority(TransactionContext c, ActiveMQDestination destination, XATransactionId xid, String clientId, String subscriptionName, long re, long re1)voidJDBCAdapter. 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)voidJdbcMemoryTransactionStore. recoverLastAck(byte[] encodedXid, ActiveMQDestination destination, String subName, String clientId)voidJDBCPersistenceAdapter. 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 voidBlobJDBCAdapter. doAddMessage(TransactionContext c, long sequence, MessageId messageID, ActiveMQDestination destination, byte[] data, long expiration, byte priority, XATransactionId xid)voidDefaultJDBCAdapter. 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 outcomevoidDefaultJDBCAdapter. doAddMessageReference(TransactionContext c, long sequence, MessageId messageID, ActiveMQDestination destination, long expirationTime, String messageRef)voidDefaultJDBCAdapter. doClearLastAck(TransactionContext c, ActiveMQDestination destination, byte priority, String clientId, String subName)voidDefaultJDBCAdapter. doDeleteSubscription(TransactionContext c, ActiveMQDestination destination, String clientId, String subscriptionName)SubscriptionInfo[]DefaultJDBCAdapter. doGetAllSubscriptions(TransactionContext c, ActiveMQDestination destination)intDefaultJDBCAdapter. doGetDurableSubscriberMessageCount(TransactionContext c, ActiveMQDestination destination, String clientId, String subscriptionName, boolean isPrioritizedMessages)longDefaultJDBCAdapter. doGetLastAckedDurableSubscriberMessageId(TransactionContext c, ActiveMQDestination destination, String clientId, String subscriberName)intDefaultJDBCAdapter. doGetMessageCount(TransactionContext c, ActiveMQDestination destination)SubscriptionInfoDefaultJDBCAdapter. doGetSubscriberEntry(TransactionContext c, ActiveMQDestination destination, String clientId, String subscriptionName)voidDefaultJDBCAdapter. doRecordDestination(TransactionContext c, ActiveMQDestination destination)voidDefaultJDBCAdapter. doRecover(TransactionContext c, ActiveMQDestination destination, JDBCMessageRecoveryListener listener)voidDefaultJDBCAdapter. doRecoverNextMessages(TransactionContext c, ActiveMQDestination destination, long[] lastRecoveredEntries, long maxSeq, int maxReturned, boolean isPrioritizedMessages, JDBCMessageRecoveryListener listener)voidDefaultJDBCAdapter. doRecoverNextMessages(TransactionContext c, ActiveMQDestination destination, String clientId, String subscriptionName, long seq, long priority, int maxReturned, JDBCMessageRecoveryListener listener)voidDefaultJDBCAdapter. doRecoverNextMessagesWithPriority(TransactionContext c, ActiveMQDestination destination, String clientId, String subscriptionName, long seq, long priority, int maxReturned, JDBCMessageRecoveryListener listener)voidDefaultJDBCAdapter. doRecoverSubscription(TransactionContext c, ActiveMQDestination destination, String clientId, String subscriptionName, JDBCMessageRecoveryListener listener)voidDefaultJDBCAdapter. doRemoveAllMessages(TransactionContext c, ActiveMQDestination destinationName)voidDefaultJDBCAdapter. doSetLastAck(TransactionContext c, ActiveMQDestination destination, XATransactionId xid, String clientId, String subscriptionName, long seq, long priority)voidDefaultJDBCAdapter. doSetLastAckWithPriority(TransactionContext c, ActiveMQDestination destination, XATransactionId xid, String clientId, String subscriptionName, long seq, long priority)voidDefaultJDBCAdapter. 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 ActiveMQDestinationKahaDBStore.KahaDBMessageStore. getDestination()ActiveMQDestinationTempKahaDBStore.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 StringMultiKahaDBPersistenceAdapter. 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 ActiveMQDestinationAmqpSupport. 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.SymbolAmqpSupport. 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 ActiveMQDestinationAmqpLink. getDestination()ActiveMQDestinationAmqpReceiver. getDestination()ActiveMQDestinationAmqpSender. getDestination()ActiveMQDestinationAmqpTransactionCoordinator. getDestination()Methods in org.apache.activemq.transport.amqp.protocol with parameters of type ActiveMQDestination Modifier and Type Method Description voidAmqpLink. setDestination(ActiveMQDestination destination)Sets the ActiveMQDestination that this link will be servicing.voidAmqpReceiver. setDestination(ActiveMQDestination destination)voidAmqpSender. setDestination(ActiveMQDestination destination)voidAmqpTransactionCoordinator. 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 ActiveMQDestinationMQTTSubscription. getDestination()The realActiveMQDestinationthat 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 ActiveMQDestinationAbstractMQTTSubscriptionStrategy. onSend(String topicName)ActiveMQDestinationMQTTSubscriptionStrategy. 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.ActiveMQDestinationMQTTVirtualTopicSubscriptionStrategy. onSend(String topicName)Methods in org.apache.activemq.transport.mqtt.strategy with parameters of type ActiveMQDestination Modifier and Type Method Description booleanAbstractMQTTSubscriptionStrategy. isControlTopic(ActiveMQDestination destination)booleanMQTTSubscriptionStrategy. 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 $).booleanMQTTVirtualTopicSubscriptionStrategy. isControlTopic(ActiveMQDestination destination)StringAbstractMQTTSubscriptionStrategy. onSend(ActiveMQDestination destination)StringMQTTSubscriptionStrategy. 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.StringMQTTVirtualTopicSubscriptionStrategy. 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 ActiveMQDestinationStompSubscription. destinationMethods in org.apache.activemq.transport.stomp that return ActiveMQDestination Modifier and Type Method Description ActiveMQDestinationFrameTranslator. convertDestination(ProtocolConverter converter, String name, boolean forceFallback)ActiveMQDestinationLegacyFrameTranslator. convertDestination(ProtocolConverter converter, String name, boolean forceFallback)ActiveMQDestinationProtocolConverter. createTempDestination(String name, boolean topic)ActiveMQDestinationStompSubscription. getDestination()Methods in org.apache.activemq.transport.stomp with parameters of type ActiveMQDestination Modifier and Type Method Description protected FrameTranslatorProtocolConverter. findTranslator(String header, ActiveMQDestination destination, boolean advisory)StringProtocolConverter. getCreatedTempDestinationName(ActiveMQDestination destination)voidStompSubscription. 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 ActiveMQDestinationNetworkBridgeUtils. 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 voidBrokerSupport. doResend(ConnectionContext context, Message originalMessage, ActiveMQDestination deadLetterDestination, boolean copy)static ActiveMQDestinationNetworkBridgeUtils. findMatchingDestination(ActiveMQDestination[] dests, ActiveMQDestination destination)static booleanNetworkBridgeUtils. isDestForcedDurable(ActiveMQDestination destination)static booleanNetworkBridgeUtils. isForcedDurable(ConsumerInfo info, ActiveMQDestination[] dynamicallyIncludedDestinations, ActiveMQDestination[] staticallyIncludedDestinations)static booleanNetworkBridgeUtils. matchesDestinations(ActiveMQDestination[] dests, ActiveMQDestination destination)static booleanNetworkBridgeUtils. matchesNetworkConfig(NetworkBridgeConfiguration config, ActiveMQDestination destination)static voidBrokerSupport. resend(ConnectionContext context, Message originalMessage, ActiveMQDestination deadLetterDestination)static voidBrokerSupport. 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 booleanNetworkBridgeUtils. 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 ActiveMQDestinationDestinationFacade. createDestination()Methods in org.apache.activemq.web with parameters of type ActiveMQDestination Modifier and Type Method Description voidBrokerFacade. purgeQueue(ActiveMQDestination destination)Purges the given destinationvoidLocalBrokerFacade. purgeQueue(ActiveMQDestination destination)voidRemoteJMXBrokerFacade. 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 voidSendMessage. sendMessages(HttpServletRequest request, WebClient client, ActiveMQDestination dest)
-