|
||||||||||
PREV NEXT | FRAMES NO FRAMES |
Packages that use ActiveMQDestination | |
---|---|
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.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 Destinations |
org.apache.activemq.broker.scheduler | |
org.apache.activemq.broker.util | Some utility Broker Plugins |
org.apache.activemq.broker.view | Broker Plugins for visualising the current system |
org.apache.activemq.command | Command objects used via the Command Pattern to communicate among nodes |
org.apache.activemq.filter | Filter implementations for wildcards & JMS selectors |
org.apache.activemq.memory.list | |
org.apache.activemq.network | Support for federated networks of brokers. |
org.apache.activemq.plugin | |
org.apache.activemq.ra | JCA managed connections and resource adapters for working with ActiveMQ |
org.apache.activemq.security | Plugable Security Adapter framework along with default implementations such as the JAAS implementation. |
org.apache.activemq.state | |
org.apache.activemq.store | The APIs which need to be implemented for persistent message stores for durable messaging |
org.apache.activemq.store.amq | The default Store implementation for ActiveMQ |
org.apache.activemq.store.jdbc | Message persistence implemented using JDBC |
org.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.kahadaptor | kaha implementation of message persistence for the broker |
org.apache.activemq.store.kahadb | |
org.apache.activemq.store.memory | VM based implementation of message persistence |
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 | Some utility classes |
Uses of ActiveMQDestination in org.apache.activemq |
---|
Methods in org.apache.activemq that return ActiveMQDestination | |
---|---|
protected ActiveMQDestination |
ActiveMQMessageConsumer.getDestination()
|
static ActiveMQDestination |
ActiveMQMessageTransformation.transformDestination(javax.jms.Destination destination)
Creates a an available JMS message from another provider. |
Methods in org.apache.activemq with parameters of type ActiveMQDestination | |
---|---|
void |
ActiveMQConnection.destroyDestination(ActiveMQDestination destination)
|
boolean |
ActiveMQConnection.isDeleted(ActiveMQDestination dest)
|
protected void |
ActiveMQSession.send(ActiveMQMessageProducer producer,
ActiveMQDestination destination,
javax.jms.Message message,
int deliveryMode,
int priority,
long timeToLive,
MemoryUsage producerWindow,
int sendTimeout)
Sends the message for dispatch by the broker. |
Constructors in org.apache.activemq with parameters of type ActiveMQDestination | |
---|---|
ActiveMQInputStream(ActiveMQConnection connection,
ConsumerId consumerId,
ActiveMQDestination dest,
java.lang.String selector,
boolean noLocal,
java.lang.String name,
int prefetch,
long timeout)
|
|
ActiveMQMessageConsumer(ActiveMQSession session,
ConsumerId consumerId,
ActiveMQDestination dest,
java.lang.String name,
java.lang.String selector,
int prefetch,
int maximumPendingMessageCount,
boolean noLocal,
boolean browser,
boolean dispatchAsync,
javax.jms.MessageListener messageListener)
Create a MessageConsumer |
|
ActiveMQMessageProducer(ActiveMQSession session,
ProducerId producerId,
ActiveMQDestination destination,
int sendTimeout)
|
|
ActiveMQOutputStream(ActiveMQConnection connection,
ProducerId producerId,
ActiveMQDestination destination,
java.util.Map<java.lang.String,java.lang.Object> properties,
int deliveryMode,
int priority,
long timeToLive)
|
|
ActiveMQQueueBrowser(ActiveMQSession session,
ConsumerId consumerId,
ActiveMQDestination destination,
java.lang.String selector,
boolean dispatchAsync)
Constructor for an ActiveMQQueueBrowser - used internally |
|
ActiveMQQueueReceiver(ActiveMQSession theSession,
ConsumerId consumerId,
ActiveMQDestination destination,
java.lang.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,
java.lang.String name,
java.lang.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 | |
---|---|
protected java.util.concurrent.ConcurrentHashMap<ActiveMQDestination,DestinationInfo> |
AdvisoryBroker.destinations
|
Methods in org.apache.activemq.advisory that return ActiveMQDestination | |
---|---|
ActiveMQDestination |
DestinationEvent.getDestination()
|
Methods in org.apache.activemq.advisory that return types with arguments of type ActiveMQDestination | |
---|---|
java.util.Map<ActiveMQDestination,DestinationInfo> |
AdvisoryBroker.getAdvisoryDestinations()
|
Constructors in org.apache.activemq.advisory with parameters of type ActiveMQDestination | |
---|---|
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 | |
---|---|
ActiveMQDestination |
DestinationAlreadyExistsException.getDestination()
|
ActiveMQDestination[] |
Broker.getDestinations()
|
ActiveMQDestination[] |
EmptyBroker.getDestinations()
|
ActiveMQDestination[] |
MutableBrokerFilter.getDestinations()
|
ActiveMQDestination[] |
BrokerFilter.getDestinations()
|
ActiveMQDestination[] |
BrokerService.getDestinations()
|
ActiveMQDestination[] |
ErrorBroker.getDestinations()
|
Methods in org.apache.activemq.broker that return types with arguments of type ActiveMQDestination | |
---|---|
java.util.Map<ActiveMQDestination,Destination> |
EmptyBroker.getDestinationMap()
|
java.util.Map<ActiveMQDestination,Destination> |
MutableBrokerFilter.getDestinationMap()
|
java.util.Map<ActiveMQDestination,Destination> |
BrokerFilter.getDestinationMap()
|
java.util.Map<ActiveMQDestination,Destination> |
ErrorBroker.getDestinationMap()
|
java.util.Set<ActiveMQDestination> |
Broker.getDurableDestinations()
|
java.util.Set<ActiveMQDestination> |
EmptyBroker.getDurableDestinations()
|
java.util.Set<ActiveMQDestination> |
MutableBrokerFilter.getDurableDestinations()
|
java.util.Set<ActiveMQDestination> |
BrokerFilter.getDurableDestinations()
|
java.util.Set<ActiveMQDestination> |
ErrorBroker.getDurableDestinations()
|
Methods in org.apache.activemq.broker with parameters of type ActiveMQDestination | |
---|---|
Destination |
EmptyBroker.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean flag)
|
Destination |
MutableBrokerFilter.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean createIfTemporary)
|
Destination |
BrokerFilter.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean createIfTemporary)
|
Destination |
ErrorBroker.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean flag)
|
Destination |
BrokerBroadcaster.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean createIfTemporary)
|
Destination |
BrokerService.getDestination(ActiveMQDestination destination)
Looks up and lazily creates if necessary the destination for the given JMS name |
java.util.Set |
EmptyBroker.getDestinations(ActiveMQDestination destination)
|
java.util.Set |
MutableBrokerFilter.getDestinations(ActiveMQDestination destination)
|
java.util.Set<Destination> |
BrokerFilter.getDestinations(ActiveMQDestination destination)
|
java.util.Set |
ErrorBroker.getDestinations(ActiveMQDestination destination)
|
void |
BrokerService.removeDestination(ActiveMQDestination destination)
|
void |
EmptyBroker.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout)
|
void |
MutableBrokerFilter.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout)
|
void |
BrokerFilter.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout)
|
void |
ErrorBroker.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout)
|
void |
BrokerBroadcaster.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout)
|
void |
BrokerService.setDestinations(ActiveMQDestination[] destinations)
Sets the destinations which should be loaded/created on startup |
Constructors in org.apache.activemq.broker with parameters of type ActiveMQDestination | |
---|---|
DestinationAlreadyExistsException(ActiveMQDestination destination)
|
Uses of ActiveMQDestination in org.apache.activemq.broker.jmx |
---|
Methods in org.apache.activemq.broker.jmx with parameters of type ActiveMQDestination | |
---|---|
protected Destination |
ManagedTopicRegion.createDestination(ConnectionContext context,
ActiveMQDestination destination)
|
protected Destination |
ManagedTempTopicRegion.createDestination(ConnectionContext context,
ActiveMQDestination destination)
|
protected Destination |
ManagedQueueRegion.createDestination(ConnectionContext context,
ActiveMQDestination destination)
|
protected Destination |
ManagedTempQueueRegion.createDestination(ConnectionContext context,
ActiveMQDestination destination)
|
protected javax.management.ObjectName |
ManagedRegionBroker.createObjectName(ActiveMQDestination destName)
|
boolean |
SubscriptionView.matchesDestination(ActiveMQDestination destination)
Return true if this subscription matches the given destination |
void |
ManagedRegionBroker.register(ActiveMQDestination destName,
Destination destination)
|
protected void |
ManagedRegionBroker.registerDestination(javax.management.ObjectName key,
ActiveMQDestination dest,
DestinationView view)
|
void |
ManagedTopicRegion.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout)
|
void |
ManagedTempTopicRegion.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout)
|
void |
ManagedQueueRegion.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout)
|
void |
ManagedTempQueueRegion.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 | |
---|---|
protected ActiveMQDestination |
BaseDestination.destination
|
Fields in org.apache.activemq.broker.region with type parameters of type ActiveMQDestination | |
---|---|
protected java.util.Map<ActiveMQDestination,Destination> |
AbstractRegion.destinations
|
Methods in org.apache.activemq.broker.region that return ActiveMQDestination | |
---|---|
ActiveMQDestination |
BaseDestination.getActiveMQDestination()
|
ActiveMQDestination |
DestinationFilter.getActiveMQDestination()
|
ActiveMQDestination |
SubscriptionRecovery.getActiveMQDestination()
|
ActiveMQDestination |
Queue.getActiveMQDestination()
|
ActiveMQDestination |
AbstractSubscription.getActiveMQDestination()
|
ActiveMQDestination |
Destination.getActiveMQDestination()
|
ActiveMQDestination[] |
RegionBroker.getDestinations()
|
Methods in org.apache.activemq.broker.region that return types with arguments of type ActiveMQDestination | |
---|---|
java.util.Map<ActiveMQDestination,Destination> |
Region.getDestinationMap()
Returns a copy of the current destinations available in the region |
java.util.Map<ActiveMQDestination,Destination> |
RegionBroker.getDestinationMap()
|
java.util.Map<ActiveMQDestination,Destination> |
AbstractRegion.getDestinationMap()
|
java.util.Set<ActiveMQDestination> |
DestinationFactoryImpl.getDestinations()
|
abstract java.util.Set<ActiveMQDestination> |
DestinationFactory.getDestinations()
Returns a set of all the ActiveMQDestination
objects that the persistence store is aware exist. |
java.util.Set<ActiveMQDestination> |
RegionBroker.getDurableDestinations()
|
protected java.util.Set<ActiveMQDestination> |
TopicRegion.getInactiveDestinations()
|
protected java.util.Set<ActiveMQDestination> |
AbstractRegion.getInactiveDestinations()
|
protected java.util.Set<ActiveMQDestination> |
QueueRegion.getInactiveDestinations()
|
Methods in org.apache.activemq.broker.region with parameters of type ActiveMQDestination | |
---|---|
Destination |
Region.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean createIfTemporary)
Used to create a destination. |
Destination |
RegionBroker.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean create)
|
Destination |
AbstractRegion.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean createIfTemporary)
|
protected void |
TempQueueRegion.configureQueue(Queue queue,
ActiveMQDestination destination)
|
protected void |
DestinationFactoryImpl.configureQueue(Queue queue,
ActiveMQDestination destination)
|
protected void |
TopicRegion.configureTopic(Topic topic,
ActiveMQDestination destination)
|
protected void |
DestinationFactoryImpl.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 messages |
int |
Queue.copyMatchingMessagesTo(ConnectionContext context,
java.lang.String selector,
ActiveMQDestination dest)
Copies the messages matching the given selector |
int |
Queue.copyMatchingMessagesTo(ConnectionContext context,
java.lang.String selector,
ActiveMQDestination dest,
int maximumMessages)
Copies the messages matching the given selector up to the maximum number of matched messages |
boolean |
Queue.copyMessageTo(ConnectionContext context,
java.lang.String messageId,
ActiveMQDestination dest)
Copies the message matching the given messageId |
void |
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)
|
Destination |
DestinationFactoryImpl.createDestination(ConnectionContext context,
ActiveMQDestination destination,
DestinationStatistics destinationStatistics)
|
abstract Destination |
DestinationFactory.createDestination(ConnectionContext context,
ActiveMQDestination destination,
DestinationStatistics destinationStatistics)
Create destination implementation. |
protected javax.jms.JMSException |
RegionBroker.createUnknownDestinationTypeException(ActiveMQDestination destination)
|
protected Destination |
TempQueueRegion.doCreateDestination(ConnectionContext context,
ActiveMQDestination destination)
|
protected abstract Destination |
AbstractTempRegion.doCreateDestination(ConnectionContext context,
ActiveMQDestination destination)
|
protected Destination |
TempTopicRegion.doCreateDestination(ConnectionContext context,
ActiveMQDestination destination)
|
java.util.Set<Destination> |
Region.getDestinations(ActiveMQDestination destination)
Provide an exact or wildcard lookup of destinations in the region |
java.util.Set<Destination> |
RegionBroker.getDestinations(ActiveMQDestination destination)
|
java.util.Set<Destination> |
AbstractRegion.getDestinations(ActiveMQDestination destination)
Provide an exact or wildcard lookup of destinations in the region |
protected Destination |
AbstractRegion.lookup(ConnectionContext context,
ActiveMQDestination destination,
boolean createTemporary)
|
boolean |
Subscription.matches(ActiveMQDestination destination)
Is the subscription interested in messages in the destination? |
boolean |
AbstractSubscription.matches(ActiveMQDestination destination)
|
int |
Queue.moveMatchingMessagesTo(ConnectionContext context,
MessageReferenceFilter filter,
ActiveMQDestination dest,
int maximumMessages)
Moves the messages matching the given filter up to the maximum number of matched messages |
int |
Queue.moveMatchingMessagesTo(ConnectionContext context,
java.lang.String selector,
ActiveMQDestination dest)
Moves the messages matching the given selector |
int |
Queue.moveMatchingMessagesTo(ConnectionContext context,
java.lang.String selector,
ActiveMQDestination dest,
int maximumMessages)
Moves the messages matching the given selector up to the maximum number of matched messages |
boolean |
Queue.moveMessageTo(ConnectionContext context,
QueueMessageReference m,
ActiveMQDestination dest)
Move a message |
boolean |
Queue.moveMessageTo(ConnectionContext context,
java.lang.String messageId,
ActiveMQDestination dest)
Moves the message matching the given messageId |
void |
RegionBroker.removeAdvisoryTopics(java.lang.String destinationType,
ConnectionContext context,
ActiveMQDestination destination,
long timeout)
|
void |
Region.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout)
Used to destroy a destination. |
void |
TempQueueRegion.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout)
|
void |
RegionBroker.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout)
|
void |
AbstractRegion.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 wildcard |
Constructors in org.apache.activemq.broker.region with parameters of type ActiveMQDestination | |
---|---|
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 | |
---|---|
protected ActiveMQDestination |
IndividualDeadLetterStrategy.createDestination(Message message,
java.lang.String prefix,
boolean useQueue,
Subscription subscription)
|
ActiveMQDestination |
SharedDeadLetterStrategy.getDeadLetterQueue()
|
ActiveMQDestination |
IndividualDeadLetterStrategy.getDeadLetterQueueFor(Message message,
Subscription subscription)
|
ActiveMQDestination |
DeadLetterStrategy.getDeadLetterQueueFor(Message message,
Subscription subscription)
Returns the dead letter queue for the given message and subscription. |
ActiveMQDestination |
SharedDeadLetterStrategy.getDeadLetterQueueFor(Message message,
Subscription subscription)
|
Methods in org.apache.activemq.broker.region.policy with parameters of type ActiveMQDestination | |
---|---|
Message[] |
TimedSubscriptionRecoveryPolicy.browse(ActiveMQDestination destination)
|
Message[] |
NoSubscriptionRecoveryPolicy.browse(ActiveMQDestination dest)
|
Message[] |
FixedSizedSubscriptionRecoveryPolicy.browse(ActiveMQDestination destination)
|
Message[] |
LastImageSubscriptionRecoveryPolicy.browse(ActiveMQDestination destination)
|
Message[] |
SubscriptionRecoveryPolicy.browse(ActiveMQDestination dest)
|
Message[] |
FixedCountSubscriptionRecoveryPolicy.browse(ActiveMQDestination destination)
|
Message[] |
QueryBasedSubscriptionRecoveryPolicy.browse(ActiveMQDestination dest)
|
void |
MessageQuery.execute(ActiveMQDestination destination,
javax.jms.MessageListener listener)
Executes the query for messages; each message is passed into the listener |
PolicyEntry |
PolicyMap.getEntryFor(ActiveMQDestination destination)
|
void |
SharedDeadLetterStrategy.setDeadLetterQueue(ActiveMQDestination deadLetterQueue)
|
Constructors in org.apache.activemq.broker.region.policy with parameters of type ActiveMQDestination | |
---|---|
SimpleDispatchSelector(ActiveMQDestination destination)
|
Uses of ActiveMQDestination in org.apache.activemq.broker.region.virtual |
---|
Methods in org.apache.activemq.broker.region.virtual that return ActiveMQDestination | |
---|---|
ActiveMQDestination |
FilteredDestination.getDestination()
|
protected ActiveMQDestination |
MirroredQueue.getMirrorTopic(ActiveMQDestination original)
|
protected ActiveMQDestination |
VirtualTopicInterceptor.getQueueConsumersWildcard(ActiveMQDestination original)
|
ActiveMQDestination |
CompositeQueue.getVirtualDestination()
|
ActiveMQDestination |
VirtualTopic.getVirtualDestination()
|
ActiveMQDestination |
VirtualDestination.getVirtualDestination()
Returns the virtual destination |
ActiveMQDestination |
CompositeTopic.getVirtualDestination()
|
Methods in org.apache.activemq.broker.region.virtual with parameters of type ActiveMQDestination | |
---|---|
void |
VirtualDestinationInterceptor.create(Broker broker,
ConnectionContext context,
ActiveMQDestination destination)
|
void |
CompositeDestination.create(Broker broker,
ConnectionContext context,
ActiveMQDestination destination)
|
void |
MirroredQueue.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 |
SelectorAwareVirtualTopicInterceptor.send(ProducerBrokerExchange context,
Message message,
ActiveMQDestination destination)
Respect the selectors of the subscriptions to ensure only matched messages are dispatched to the virtual queues, hence there is no build up of unmatched messages on these destinations |
void |
FilteredDestination.setDestination(ActiveMQDestination destination)
The destination to send messages to if they match the filter |
Uses of ActiveMQDestination in org.apache.activemq.broker.scheduler |
---|
Methods in org.apache.activemq.broker.scheduler with parameters of type ActiveMQDestination | |
---|---|
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 | |
---|---|
protected ActiveMQDestination |
DestinationPathSeparatorBroker.convertDestination(ActiveMQDestination destination)
|
ActiveMQDestination[] |
LoggingBrokerPlugin.getDestinations()
|
Methods in org.apache.activemq.broker.util that return types with arguments of type ActiveMQDestination | |
---|---|
java.util.Set<ActiveMQDestination> |
LoggingBrokerPlugin.getDurableDestinations()
|
Methods in org.apache.activemq.broker.util with parameters of type ActiveMQDestination | |
---|---|
Destination |
DestinationPathSeparatorBroker.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean createIfTemporary)
|
Destination |
LoggingBrokerPlugin.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean create)
|
protected ActiveMQDestination |
DestinationPathSeparatorBroker.convertDestination(ActiveMQDestination destination)
|
void |
DestinationPathSeparatorBroker.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 with parameters of type ActiveMQDestination | |
---|---|
Destination |
DestinationDotFileInterceptor.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean create)
|
void |
DestinationDotFileInterceptor.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout)
|
Uses of ActiveMQDestination in org.apache.activemq.command |
---|
Subclasses of ActiveMQDestination in org.apache.activemq.command | |
---|---|
class |
ActiveMQQueue
|
class |
ActiveMQTempDestination
|
class |
ActiveMQTempQueue
|
class |
ActiveMQTempTopic
|
class |
ActiveMQTopic
|
Fields in org.apache.activemq.command declared as ActiveMQDestination | |
---|---|
protected ActiveMQDestination[] |
ActiveMQDestination.compositeDestinations
|
protected ActiveMQDestination |
MessagePull.destination
|
protected ActiveMQDestination |
MessageAck.destination
|
protected ActiveMQDestination |
ConsumerControl.destination
|
protected ActiveMQDestination |
DestinationInfo.destination
|
protected ActiveMQDestination |
Message.destination
|
protected ActiveMQDestination |
MessageDispatch.destination
|
protected ActiveMQDestination |
SubscriptionInfo.destination
|
protected ActiveMQDestination |
ConsumerInfo.destination
|
protected ActiveMQDestination |
MessageDispatchNotification.destination
|
protected ActiveMQDestination |
ProducerInfo.destination
|
protected ActiveMQDestination |
Message.originalDestination
|
protected ActiveMQDestination |
Message.replyTo
|
protected ActiveMQDestination |
SubscriptionInfo.subscribedDestination
|
Methods in org.apache.activemq.command that return ActiveMQDestination | |
---|---|
ActiveMQDestination |
ActiveMQDestination.createDestination(java.lang.String name)
|
static ActiveMQDestination |
ActiveMQDestination.createDestination(java.lang.String name,
byte defaultType)
|
ActiveMQDestination[] |
ActiveMQDestination.getCompositeDestinations()
|
ActiveMQDestination |
MessagePull.getDestination()
|
ActiveMQDestination |
MessageAck.getDestination()
|
ActiveMQDestination |
ConsumerControl.getDestination()
|
ActiveMQDestination |
JournalQueueAck.getDestination()
|
ActiveMQDestination |
DestinationInfo.getDestination()
|
ActiveMQDestination |
JournalTopicAck.getDestination()
|
ActiveMQDestination |
Message.getDestination()
|
ActiveMQDestination |
MessageDispatch.getDestination()
|
ActiveMQDestination |
SubscriptionInfo.getDestination()
This is the a resolved destination that the subscription is receiving messages from. |
ActiveMQDestination |
ConsumerInfo.getDestination()
The destination that the consumer is interested in receiving messages from. |
ActiveMQDestination |
MessageDispatchNotification.getDestination()
|
ActiveMQDestination |
ProducerInfo.getDestination()
|
ActiveMQDestination |
Message.getOriginalDestination()
|
ActiveMQDestination |
Message.getReplyTo()
|
ActiveMQDestination |
SubscriptionInfo.getSubscribedDestination()
The destination the client originally subscribed to.. |
static ActiveMQDestination |
ActiveMQDestination.transform(javax.jms.Destination dest)
|
Methods in org.apache.activemq.command with parameters of type ActiveMQDestination | |
---|---|
static int |
ActiveMQDestination.compare(ActiveMQDestination destination,
ActiveMQDestination destination2)
|
void |
ActiveMQDestination.setCompositeDestinations(ActiveMQDestination[] destinations)
|
void |
MessagePull.setDestination(ActiveMQDestination destination)
|
void |
MessageAck.setDestination(ActiveMQDestination destination)
|
void |
ConsumerControl.setDestination(ActiveMQDestination destination)
|
void |
JournalQueueAck.setDestination(ActiveMQDestination destination)
|
void |
DestinationInfo.setDestination(ActiveMQDestination destination)
|
void |
JournalTopicAck.setDestination(ActiveMQDestination destination)
|
void |
Message.setDestination(ActiveMQDestination destination)
|
void |
MessageDispatch.setDestination(ActiveMQDestination destination)
|
void |
SubscriptionInfo.setDestination(ActiveMQDestination destination)
|
void |
ConsumerInfo.setDestination(ActiveMQDestination destination)
|
void |
MessageDispatchNotification.setDestination(ActiveMQDestination destination)
|
void |
ProducerInfo.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 | |
---|---|
ActiveMQDestination(ActiveMQDestination[] composites)
|
|
DestinationInfo(ConnectionId connectionId,
byte operationType,
ActiveMQDestination destination)
|
Uses of ActiveMQDestination in org.apache.activemq.filter |
---|
Fields in org.apache.activemq.filter declared as ActiveMQDestination | |
---|---|
protected ActiveMQDestination |
MessageEvaluationContext.destination
|
Methods in org.apache.activemq.filter that return ActiveMQDestination | |
---|---|
ActiveMQDestination |
MessageEvaluationContext.getDestination()
|
ActiveMQDestination |
DestinationMapEntry.getDestination()
|
Methods in org.apache.activemq.filter with parameters of type ActiveMQDestination | |
---|---|
java.lang.Object |
DestinationMap.chooseValue(ActiveMQDestination destination)
Returns the value which matches the given destination or null if there is no matching value. |
protected java.util.Set |
DestinationMap.findWildcardMatches(ActiveMQDestination key)
|
java.util.Set |
DestinationMap.get(ActiveMQDestination key)
Looks up the value(s) matching the given Destination key. |
static java.lang.String[] |
DestinationPath.getDestinationPaths(ActiveMQDestination destination)
|
protected DestinationMapNode |
DestinationMap.getRootNode(ActiveMQDestination key)
Returns the root node for the given destination type |
abstract boolean |
DestinationFilter.matches(ActiveMQDestination destination)
|
boolean |
WildcardDestinationFilter.matches(ActiveMQDestination destination)
|
boolean |
PrefixDestinationFilter.matches(ActiveMQDestination destination)
|
boolean |
CompositeDestinationFilter.matches(ActiveMQDestination destination)
|
boolean |
SimpleDestinationFilter.matches(ActiveMQDestination destination)
|
static DestinationFilter |
DestinationFilter.parseFilter(ActiveMQDestination destination)
|
void |
DestinationMap.put(ActiveMQDestination key,
java.lang.Object value)
|
void |
DestinationMap.remove(ActiveMQDestination key,
java.lang.Object value)
Removes the value from the associated destination |
java.util.Set |
DestinationMap.removeAll(ActiveMQDestination key)
|
void |
MessageEvaluationContext.setDestination(ActiveMQDestination destination)
|
void |
DestinationMapEntry.setDestination(ActiveMQDestination destination)
|
Constructors in org.apache.activemq.filter with parameters of type ActiveMQDestination | |
---|---|
CompositeDestinationFilter(ActiveMQDestination destination)
|
|
SimpleDestinationFilter(ActiveMQDestination destination)
|
Uses of ActiveMQDestination in org.apache.activemq.memory.list |
---|
Methods in org.apache.activemq.memory.list with parameters of type ActiveMQDestination | |
---|---|
Message[] |
SimpleMessageList.browse(ActiveMQDestination destination)
|
Message[] |
MessageList.browse(ActiveMQDestination destination)
|
Message[] |
DestinationBasedMessageList.browse(ActiveMQDestination destination)
|
java.util.List<MessageReference> |
SimpleMessageList.getMessages(ActiveMQDestination destination)
|
java.util.List |
MessageList.getMessages(ActiveMQDestination destination)
Returns the current list of MessageReference objects for the given subscription |
java.util.List<MessageReference> |
DestinationBasedMessageList.getMessages(ActiveMQDestination destination)
|
Uses of ActiveMQDestination in org.apache.activemq.network |
---|
Fields in org.apache.activemq.network declared as ActiveMQDestination | |
---|---|
protected ActiveMQDestination[] |
DemandForwardingBridgeSupport.durableDestinations
|
protected ActiveMQDestination[] |
DemandForwardingBridgeSupport.dynamicallyIncludedDestinations
|
protected ActiveMQDestination[] |
DemandForwardingBridgeSupport.excludedDestinations
|
protected ActiveMQDestination[] |
DemandForwardingBridgeSupport.staticallyIncludedDestinations
|
Methods in org.apache.activemq.network that return ActiveMQDestination | |
---|---|
ActiveMQDestination[] |
DemandForwardingBridgeSupport.getDurableDestinations()
|
ActiveMQDestination[] |
DemandForwardingBridgeSupport.getDynamicallyIncludedDestinations()
|
ActiveMQDestination[] |
DemandForwardingBridgeSupport.getExcludedDestinations()
|
ActiveMQDestination[] |
DemandForwardingBridgeSupport.getStaticallyIncludedDestinations()
|
Methods in org.apache.activemq.network that return types with arguments of type ActiveMQDestination | |
---|---|
java.util.List<ActiveMQDestination> |
NetworkBridgeConfiguration.getDynamicallyIncludedDestinations()
|
java.util.List<ActiveMQDestination> |
NetworkConnector.getDynamicallyIncludedDestinations()
|
java.util.List<ActiveMQDestination> |
NetworkBridgeConfiguration.getExcludedDestinations()
|
java.util.List<ActiveMQDestination> |
NetworkConnector.getExcludedDestinations()
|
java.util.List<ActiveMQDestination> |
NetworkBridgeConfiguration.getStaticallyIncludedDestinations()
|
java.util.List<ActiveMQDestination> |
NetworkConnector.getStaticallyIncludedDestinations()
|
Methods in org.apache.activemq.network with parameters of type ActiveMQDestination | |
---|---|
void |
NetworkConnector.addDynamicallyIncludedDestination(ActiveMQDestination destiantion)
|
void |
NetworkConnector.addExcludedDestination(ActiveMQDestination destiantion)
|
void |
NetworkConnector.addStaticallyIncludedDestination(ActiveMQDestination destiantion)
|
protected DemandSubscription |
DemandForwardingBridgeSupport.createDemandSubscription(ActiveMQDestination destination)
|
protected boolean |
DurableConduitBridge.doesConsumerExist(ActiveMQDestination dest)
|
protected java.lang.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 | |
---|---|
void |
NetworkConnector.setDurableDestinations(java.util.Set<ActiveMQDestination> durableDestinations)
|
void |
NetworkBridgeConfiguration.setDynamicallyIncludedDestinations(java.util.List<ActiveMQDestination> dynamicallyIncludedDestinations)
|
void |
NetworkConnector.setDynamicallyIncludedDestinations(java.util.List<ActiveMQDestination> dynamicallyIncludedDestinations)
|
void |
NetworkBridgeConfiguration.setExcludedDestinations(java.util.List<ActiveMQDestination> excludedDestinations)
|
void |
NetworkConnector.setExcludedDestinations(java.util.List<ActiveMQDestination> excludedDestinations)
|
void |
NetworkBridgeConfiguration.setStaticallyIncludedDestinations(java.util.List<ActiveMQDestination> staticallyIncludedDestinations)
|
void |
NetworkConnector.setStaticallyIncludedDestinations(java.util.List<ActiveMQDestination> staticallyIncludedDestinations)
|
Uses of ActiveMQDestination in org.apache.activemq.plugin |
---|
Methods in org.apache.activemq.plugin with parameters of type ActiveMQDestination | |
---|---|
protected void |
StatisticsBroker.sendStats(ConnectionContext context,
ActiveMQMapMessage msg,
ActiveMQDestination replyTo)
|
Uses of ActiveMQDestination in org.apache.activemq.ra |
---|
Methods in org.apache.activemq.ra that return ActiveMQDestination | |
---|---|
ActiveMQDestination |
ActiveMQActivationSpec.createDestination()
|
Methods in org.apache.activemq.ra with parameters of type ActiveMQDestination | |
---|---|
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 |
---|
Methods in org.apache.activemq.security that return types with arguments of type ActiveMQDestination | |
---|---|
java.util.concurrent.ConcurrentHashMap<ActiveMQDestination,ActiveMQDestination> |
SecurityContext.getAuthorizedReadDests()
|
java.util.concurrent.ConcurrentHashMap<ActiveMQDestination,ActiveMQDestination> |
SecurityContext.getAuthorizedReadDests()
|
java.util.concurrent.ConcurrentHashMap<ActiveMQDestination,ActiveMQDestination> |
SecurityContext.getAuthorizedWriteDests()
|
java.util.concurrent.ConcurrentHashMap<ActiveMQDestination,ActiveMQDestination> |
SecurityContext.getAuthorizedWriteDests()
|
Methods in org.apache.activemq.security with parameters of type ActiveMQDestination | |
---|---|
Destination |
AuthorizationBroker.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean create)
|
protected java.util.Set<GroupPrincipal> |
LDAPAuthorizationMap.getACLs(ActiveMQDestination destination,
java.lang.String roleBase,
java.lang.String roleAttribute)
|
java.util.Set<GroupPrincipal> |
LDAPAuthorizationMap.getAdminACLs(ActiveMQDestination destination)
|
java.util.Set<java.lang.Object> |
DefaultAuthorizationMap.getAdminACLs(ActiveMQDestination destination)
|
java.util.Set<java.lang.Object> |
SimpleAuthorizationMap.getAdminACLs(ActiveMQDestination destination)
|
java.util.Set<?> |
AuthorizationMap.getAdminACLs(ActiveMQDestination destination)
Returns the set of all ACLs capable of administering the given destination |
protected java.util.Set<AuthorizationEntry> |
DefaultAuthorizationMap.getAllEntries(ActiveMQDestination destination)
|
AuthorizationEntry |
DefaultAuthorizationMap.getEntryFor(ActiveMQDestination destination)
|
java.util.Set<GroupPrincipal> |
LDAPAuthorizationMap.getReadACLs(ActiveMQDestination destination)
|
java.util.Set<java.lang.Object> |
DefaultAuthorizationMap.getReadACLs(ActiveMQDestination destination)
|
java.util.Set<java.lang.Object> |
SimpleAuthorizationMap.getReadACLs(ActiveMQDestination destination)
|
java.util.Set<?> |
AuthorizationMap.getReadACLs(ActiveMQDestination destination)
Returns the set of all ACLs capable of reading (consuming from) the given destination |
java.util.Set<GroupPrincipal> |
LDAPAuthorizationMap.getWriteACLs(ActiveMQDestination destination)
|
java.util.Set<java.lang.Object> |
DefaultAuthorizationMap.getWriteACLs(ActiveMQDestination destination)
|
java.util.Set<java.lang.Object> |
SimpleAuthorizationMap.getWriteACLs(ActiveMQDestination destination)
|
java.util.Set<?> |
AuthorizationMap.getWriteACLs(ActiveMQDestination destination)
Returns the set of all ACLs capable of writing to the given destination |
void |
AuthorizationBroker.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout)
|
Uses of ActiveMQDestination in org.apache.activemq.state |
---|
Methods in org.apache.activemq.state with parameters of type ActiveMQDestination | |
---|---|
void |
ConnectionState.removeTempDestination(ActiveMQDestination destination)
|
Uses of ActiveMQDestination in org.apache.activemq.store |
---|
Fields in org.apache.activemq.store declared as ActiveMQDestination | |
---|---|
protected ActiveMQDestination |
AbstractMessageStore.destination
|
Methods in org.apache.activemq.store that return ActiveMQDestination | |
---|---|
ActiveMQDestination |
MessageStore.getDestination()
The destination that the message store is holding messages for. |
ActiveMQDestination |
AbstractMessageStore.getDestination()
|
ActiveMQDestination |
ProxyTopicMessageStore.getDestination()
|
ActiveMQDestination |
ProxyMessageStore.getDestination()
|
Methods in org.apache.activemq.store that return types with arguments of type ActiveMQDestination | |
---|---|
java.util.Set<ActiveMQDestination> |
PersistenceAdapter.getDestinations()
Returns a set of all the ActiveMQDestination
objects that the persistence store is aware exist. |
Constructors in org.apache.activemq.store with parameters of type ActiveMQDestination | |
---|---|
AbstractMessageStore(ActiveMQDestination destination)
|
Uses of ActiveMQDestination in org.apache.activemq.store.amq |
---|
Methods in org.apache.activemq.store.amq that return types with arguments of type ActiveMQDestination | |
---|---|
java.util.Set<ActiveMQDestination> |
AMQPersistenceAdapter.getDestinations()
|
Constructors in org.apache.activemq.store.amq with parameters of type ActiveMQDestination | |
---|---|
AMQMessageStore(AMQPersistenceAdapter adapter,
ReferenceStore referenceStore,
ActiveMQDestination destination)
|
|
AMQTxOperation(byte operationType,
ActiveMQDestination destination,
java.lang.Object data,
Location location)
|
Uses of ActiveMQDestination in org.apache.activemq.store.jdbc |
---|
Methods in org.apache.activemq.store.jdbc that return types with arguments of type ActiveMQDestination | |
---|---|
java.util.Set<ActiveMQDestination> |
JDBCAdapter.doGetDestinations(TransactionContext c)
|
java.util.Set<ActiveMQDestination> |
JDBCPersistenceAdapter.getDestinations()
|
Methods in org.apache.activemq.store.jdbc with parameters of type ActiveMQDestination | |
---|---|
void |
JDBCAdapter.doAddMessage(TransactionContext c,
long sequence,
MessageId messageID,
ActiveMQDestination destination,
byte[] data,
long expiration,
byte priority)
|
void |
JDBCAdapter.doAddMessageReference(TransactionContext c,
long sequence,
MessageId messageId,
ActiveMQDestination destination,
long expirationTime,
java.lang.String messageRef)
|
void |
JDBCAdapter.doDeleteSubscription(TransactionContext c,
ActiveMQDestination destinationName,
java.lang.String clientId,
java.lang.String subscriptionName)
|
SubscriptionInfo[] |
JDBCAdapter.doGetAllSubscriptions(TransactionContext c,
ActiveMQDestination destination)
|
int |
JDBCAdapter.doGetDurableSubscriberMessageCount(TransactionContext c,
ActiveMQDestination destination,
java.lang.String clientId,
java.lang.String subscriptionName,
boolean isPrioritizeMessages)
|
long |
JDBCAdapter.doGetLastAckedDurableSubscriberMessageId(TransactionContext c,
ActiveMQDestination destination,
java.lang.String clientId,
java.lang.String subscriberName)
|
int |
JDBCAdapter.doGetMessageCount(TransactionContext c,
ActiveMQDestination destination)
|
SubscriptionInfo |
JDBCAdapter.doGetSubscriberEntry(TransactionContext c,
ActiveMQDestination destination,
java.lang.String clientId,
java.lang.String subscriptionName)
|
void |
JDBCAdapter.doRecover(TransactionContext c,
ActiveMQDestination destination,
JDBCMessageRecoveryListener listener)
|
void |
JDBCAdapter.doRecoverNextMessages(TransactionContext c,
ActiveMQDestination destination,
long nextSeq,
long priority,
int maxReturned,
boolean isPrioritizeMessages,
JDBCMessageRecoveryListener listener)
|
void |
JDBCAdapter.doRecoverNextMessages(TransactionContext c,
ActiveMQDestination destination,
java.lang.String clientId,
java.lang.String subscriptionName,
long seq,
long priority,
int maxReturned,
JDBCMessageRecoveryListener listener)
|
void |
JDBCAdapter.doRecoverNextMessagesWithPriority(TransactionContext c,
ActiveMQDestination destination,
java.lang.String clientId,
java.lang.String subscriptionName,
long seq,
long priority,
int maxReturned,
JDBCMessageRecoveryListener listener)
|
void |
JDBCAdapter.doRecoverSubscription(TransactionContext c,
ActiveMQDestination destination,
java.lang.String clientId,
java.lang.String subscriptionName,
JDBCMessageRecoveryListener listener)
|
void |
JDBCAdapter.doRemoveAllMessages(TransactionContext c,
ActiveMQDestination destinationName)
|
void |
JDBCAdapter.doSetLastAck(TransactionContext c,
ActiveMQDestination destination,
java.lang.String clientId,
java.lang.String subscriptionName,
long seq,
long prio)
|
void |
JDBCAdapter.doSetLastAckWithPriority(TransactionContext c,
ActiveMQDestination destination,
java.lang.String clientId,
java.lang.String subscriptionName,
long re,
long re1)
|
long[] |
JDBCAdapter.getStoreSequenceId(TransactionContext c,
ActiveMQDestination destination,
MessageId messageID)
|
Constructors in org.apache.activemq.store.jdbc with parameters of type ActiveMQDestination | |
---|---|
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 | |
---|---|
java.util.Set<ActiveMQDestination> |
DefaultJDBCAdapter.doGetDestinations(TransactionContext c)
|
Methods in org.apache.activemq.store.jdbc.adapter with parameters of type ActiveMQDestination | |
---|---|
void |
DefaultJDBCAdapter.doAddMessage(TransactionContext c,
long sequence,
MessageId messageID,
ActiveMQDestination destination,
byte[] data,
long expiration,
byte priority)
|
void |
DefaultJDBCAdapter.doAddMessageReference(TransactionContext c,
long sequence,
MessageId messageID,
ActiveMQDestination destination,
long expirationTime,
java.lang.String messageRef)
|
void |
DefaultJDBCAdapter.doDeleteSubscription(TransactionContext c,
ActiveMQDestination destination,
java.lang.String clientId,
java.lang.String subscriptionName)
|
SubscriptionInfo[] |
DefaultJDBCAdapter.doGetAllSubscriptions(TransactionContext c,
ActiveMQDestination destination)
|
int |
DefaultJDBCAdapter.doGetDurableSubscriberMessageCount(TransactionContext c,
ActiveMQDestination destination,
java.lang.String clientId,
java.lang.String subscriptionName,
boolean isPrioritizedMessages)
|
long |
DefaultJDBCAdapter.doGetLastAckedDurableSubscriberMessageId(TransactionContext c,
ActiveMQDestination destination,
java.lang.String clientId,
java.lang.String subscriberName)
|
int |
DefaultJDBCAdapter.doGetMessageCount(TransactionContext c,
ActiveMQDestination destination)
|
byte[] |
DefaultJDBCAdapter.doGetNextDurableSubscriberMessageStatement(TransactionContext c,
ActiveMQDestination destination,
java.lang.String clientId,
java.lang.String subscriberName)
|
SubscriptionInfo |
DefaultJDBCAdapter.doGetSubscriberEntry(TransactionContext c,
ActiveMQDestination destination,
java.lang.String clientId,
java.lang.String subscriptionName)
|
void |
DefaultJDBCAdapter.doRecover(TransactionContext c,
ActiveMQDestination destination,
JDBCMessageRecoveryListener listener)
|
void |
DefaultJDBCAdapter.doRecoverNextMessages(TransactionContext c,
ActiveMQDestination destination,
long nextSeq,
long priority,
int maxReturned,
boolean isPrioritizedMessages,
JDBCMessageRecoveryListener listener)
|
void |
DefaultJDBCAdapter.doRecoverNextMessages(TransactionContext c,
ActiveMQDestination destination,
java.lang.String clientId,
java.lang.String subscriptionName,
long seq,
long priority,
int maxReturned,
JDBCMessageRecoveryListener listener)
|
void |
DefaultJDBCAdapter.doRecoverNextMessagesWithPriority(TransactionContext c,
ActiveMQDestination destination,
java.lang.String clientId,
java.lang.String subscriptionName,
long seq,
long priority,
int maxReturned,
JDBCMessageRecoveryListener listener)
|
void |
DefaultJDBCAdapter.doRecoverSubscription(TransactionContext c,
ActiveMQDestination destination,
java.lang.String clientId,
java.lang.String subscriptionName,
JDBCMessageRecoveryListener listener)
|
void |
DefaultJDBCAdapter.doRemoveAllMessages(TransactionContext c,
ActiveMQDestination destinationName)
|
void |
DefaultJDBCAdapter.doSetLastAck(TransactionContext c,
ActiveMQDestination destination,
java.lang.String clientId,
java.lang.String subscriptionName,
long seq,
long priority)
|
void |
DefaultJDBCAdapter.doSetLastAckWithPriority(TransactionContext c,
ActiveMQDestination destination,
java.lang.String clientId,
java.lang.String subscriptionName,
long seq,
long prio)
|
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 | |
---|---|
java.util.Set<ActiveMQDestination> |
JournalPersistenceAdapter.getDestinations()
|
Constructors in org.apache.activemq.store.journal with parameters of type ActiveMQDestination | |
---|---|
JournalMessageStore(JournalPersistenceAdapter adapter,
MessageStore checkpointStore,
ActiveMQDestination destination)
|
Uses of ActiveMQDestination in org.apache.activemq.store.kahadaptor |
---|
Fields in org.apache.activemq.store.kahadaptor with type parameters of type ActiveMQDestination | |
---|---|
protected java.util.concurrent.ConcurrentHashMap<ActiveMQDestination,MessageStore> |
KahaPersistenceAdapter.messageStores
|
Methods in org.apache.activemq.store.kahadaptor that return types with arguments of type ActiveMQDestination | |
---|---|
java.util.Set<ActiveMQDestination> |
KahaPersistenceAdapter.getDestinations()
|
Constructors in org.apache.activemq.store.kahadaptor with parameters of type ActiveMQDestination | |
---|---|
KahaMessageStore(MapContainer<MessageId,Message> container,
ActiveMQDestination destination)
|
|
KahaReferenceStore(KahaReferenceStoreAdapter adapter,
MapContainer<MessageId,ReferenceRecord> container,
ActiveMQDestination destination)
|
|
KahaTopicMessageStore(Store store,
MapContainer<MessageId,Message> messageContainer,
ListContainer<TopicSubAck> ackContainer,
MapContainer<java.lang.String,SubscriptionInfo> subsContainer,
ActiveMQDestination destination)
|
|
KahaTopicReferenceStore(Store store,
KahaReferenceStoreAdapter adapter,
MapContainer<MessageId,ReferenceRecord> messageContainer,
ListContainer<TopicSubAck> ackContainer,
MapContainer<java.lang.String,SubscriptionInfo> subsContainer,
ActiveMQDestination destination)
|
Uses of ActiveMQDestination in org.apache.activemq.store.kahadb |
---|
Methods in org.apache.activemq.store.kahadb that return ActiveMQDestination | |
---|---|
ActiveMQDestination |
KahaDBStore.KahaDBMessageStore.getDestination()
|
ActiveMQDestination |
TempKahaDBStore.KahaDBMessageStore.getDestination()
|
Methods in org.apache.activemq.store.kahadb that return types with arguments of type ActiveMQDestination | |
---|---|
java.util.Set<ActiveMQDestination> |
KahaDBStore.getDestinations()
|
java.util.Set<ActiveMQDestination> |
TempKahaDBStore.getDestinations()
|
java.util.Set<ActiveMQDestination> |
KahaDBPersistenceAdapter.getDestinations()
|
Constructors in org.apache.activemq.store.kahadb with parameters of type ActiveMQDestination | |
---|---|
KahaDBStore.KahaDBMessageStore(ActiveMQDestination destination)
|
|
TempKahaDBStore.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 | |
---|---|
java.util.Set<ActiveMQDestination> |
MemoryPersistenceAdapter.getDestinations()
|
Constructors in org.apache.activemq.store.memory with parameters of type ActiveMQDestination | |
---|---|
MemoryMessageStore(ActiveMQDestination destination)
|
|
MemoryMessageStore(ActiveMQDestination destination,
java.util.Map<MessageId,Message> messageTable)
|
|
MemoryTopicMessageStore(ActiveMQDestination destination)
|
|
MemoryTopicMessageStore(ActiveMQDestination destination,
java.util.Map<MessageId,Message> messageTable,
java.util.Map<SubscriptionKey,SubscriptionInfo> subscriberDatabase)
|
Uses of ActiveMQDestination in org.apache.activemq.transport.stomp |
---|
Methods in org.apache.activemq.transport.stomp that return ActiveMQDestination | |
---|---|
ActiveMQDestination |
FrameTranslator.convertDestination(ProtocolConverter converter,
java.lang.String name)
|
ActiveMQDestination |
LegacyFrameTranslator.convertDestination(ProtocolConverter converter,
java.lang.String name)
|
ActiveMQDestination |
ProtocolConverter.createTempQueue(java.lang.String name)
|
ActiveMQDestination |
ProtocolConverter.createTempTopic(java.lang.String name)
|
ActiveMQDestination |
StompSubscription.getDestination()
|
Methods in org.apache.activemq.transport.stomp with parameters of type ActiveMQDestination | |
---|---|
java.lang.String |
ProtocolConverter.getCreatedTempDestinationName(ActiveMQDestination destination)
|
void |
StompSubscription.setDestination(ActiveMQDestination destination)
|
Uses of ActiveMQDestination in org.apache.activemq.util |
---|
Methods in org.apache.activemq.util with parameters of type ActiveMQDestination | |
---|---|
static void |
BrokerSupport.doResend(ConnectionContext context,
Message originalMessage,
ActiveMQDestination deadLetterDestination,
boolean copy)
|
static void |
BrokerSupport.resend(ConnectionContext context,
Message originalMessage,
ActiveMQDestination deadLetterDestination)
|
static void |
BrokerSupport.resendNoCopy(ConnectionContext context,
Message originalMessage,
ActiveMQDestination deadLetterDestination)
|
|
||||||||||
PREV NEXT | FRAMES NO FRAMES |