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.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.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.util |
Some utility classes
|
Modifier and Type | Method and Description |
---|---|
protected ActiveMQDestination |
ActiveMQMessageConsumer.getDestination() |
static ActiveMQDestination |
ActiveMQMessageTransformation.transformDestination(javax.jms.Destination destination)
Creates a an available JMS message from another provider.
|
Modifier and Type | Method and Description |
---|---|
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,
AsyncCallback onComplete)
Sends the message for dispatch by the broker.
|
Constructor and Description |
---|
ActiveMQInputStream(ActiveMQConnection connection,
ConsumerId consumerId,
ActiveMQDestination dest,
String selector,
boolean noLocal,
String name,
int prefetch,
long timeout) |
ActiveMQMessageConsumer(ActiveMQSession session,
ConsumerId consumerId,
ActiveMQDestination dest,
String name,
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,
Map<String,Object> properties,
int deliveryMode,
int priority,
long timeToLive) |
ActiveMQQueueBrowser(ActiveMQSession session,
ConsumerId consumerId,
ActiveMQDestination destination,
String selector,
boolean dispatchAsync)
Constructor for an ActiveMQQueueBrowser - used internally
|
ActiveMQQueueReceiver(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) |
Modifier and Type | Field and Description |
---|---|
protected ConcurrentHashMap<ActiveMQDestination,DestinationInfo> |
AdvisoryBroker.destinations |
Modifier and Type | Method and Description |
---|---|
ActiveMQDestination |
DestinationEvent.getDestination() |
Modifier and Type | Method and Description |
---|---|
Map<ActiveMQDestination,DestinationInfo> |
AdvisoryBroker.getAdvisoryDestinations() |
Constructor and 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) |
Modifier and Type | Method and Description |
---|---|
ActiveMQDestination |
DestinationAlreadyExistsException.getDestination() |
ActiveMQDestination[] |
MutableBrokerFilter.getDestinations() |
ActiveMQDestination[] |
Broker.getDestinations() |
ActiveMQDestination[] |
ErrorBroker.getDestinations() |
ActiveMQDestination[] |
BrokerFilter.getDestinations() |
ActiveMQDestination[] |
EmptyBroker.getDestinations() |
ActiveMQDestination[] |
BrokerService.getDestinations() |
Modifier and Type | Method and Description |
---|---|
Map<ActiveMQDestination,Destination> |
MutableBrokerFilter.getDestinationMap() |
Map<ActiveMQDestination,Destination> |
ErrorBroker.getDestinationMap() |
Map<ActiveMQDestination,Destination> |
BrokerFilter.getDestinationMap() |
Map<ActiveMQDestination,Destination> |
EmptyBroker.getDestinationMap() |
Set<ActiveMQDestination> |
MutableBrokerFilter.getDurableDestinations() |
Set<ActiveMQDestination> |
Broker.getDurableDestinations() |
Set<ActiveMQDestination> |
ErrorBroker.getDurableDestinations() |
Set<ActiveMQDestination> |
BrokerFilter.getDurableDestinations() |
Set<ActiveMQDestination> |
EmptyBroker.getDurableDestinations() |
Modifier and Type | Method and Description |
---|---|
Destination |
MutableBrokerFilter.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean createIfTemporary) |
Destination |
ErrorBroker.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean flag) |
Destination |
BrokerFilter.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean createIfTemporary) |
Destination |
EmptyBroker.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
|
Set |
MutableBrokerFilter.getDestinations(ActiveMQDestination destination) |
Set |
ErrorBroker.getDestinations(ActiveMQDestination destination) |
Set<Destination> |
BrokerFilter.getDestinations(ActiveMQDestination destination) |
Set |
EmptyBroker.getDestinations(ActiveMQDestination destination) |
void |
BrokerService.removeDestination(ActiveMQDestination destination) |
void |
MutableBrokerFilter.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
void |
ErrorBroker.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
void |
BrokerFilter.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
void |
EmptyBroker.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
|
boolean |
BrokerService.shouldRecordVirtualDestination(ActiveMQDestination destination) |
Constructor and Description |
---|
DestinationAlreadyExistsException(ActiveMQDestination destination) |
Modifier and Type | Field and Description |
---|---|
protected ActiveMQDestination |
ProducerView.lastUsedDestination |
Modifier and Type | Method and Description |
---|---|
protected Destination |
ManagedQueueRegion.createDestination(ConnectionContext context,
ActiveMQDestination destination) |
protected Destination |
ManagedTempTopicRegion.createDestination(ConnectionContext context,
ActiveMQDestination destination) |
protected Destination |
ManagedTempQueueRegion.createDestination(ConnectionContext context,
ActiveMQDestination destination) |
protected Destination |
ManagedTopicRegion.createDestination(ConnectionContext context,
ActiveMQDestination destination) |
protected 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(ObjectName key,
ActiveMQDestination dest,
DestinationView view) |
protected void |
ManagedRegionBroker.registerProducer(ObjectName key,
ActiveMQDestination dest,
ProducerView view) |
void |
ManagedQueueRegion.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
void |
ManagedTempTopicRegion.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
void |
ManagedTempQueueRegion.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
void |
ManagedTopicRegion.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
void |
ManagedRegionBroker.unregister(ActiveMQDestination destName) |
Modifier and Type | Field and Description |
---|---|
protected ActiveMQDestination |
BaseDestination.destination |
Modifier and Type | Field and Description |
---|---|
protected Map<ActiveMQDestination,Destination> |
AbstractRegion.destinations |
Modifier and Type | Method and Description |
---|---|
ActiveMQDestination |
Destination.getActiveMQDestination() |
ActiveMQDestination |
DestinationFilter.getActiveMQDestination() |
ActiveMQDestination |
SubscriptionRecovery.getActiveMQDestination() |
ActiveMQDestination |
BaseDestination.getActiveMQDestination() |
ActiveMQDestination |
AbstractSubscription.getActiveMQDestination() |
ActiveMQDestination |
Queue.getActiveMQDestination() |
ActiveMQDestination[] |
RegionBroker.getDestinations() |
Modifier and Type | Method and Description |
---|---|
Map<ActiveMQDestination,Destination> |
Region.getDestinationMap()
Returns a reference to the concurrent hash map that holds known destinations, do not modify
|
Map<ActiveMQDestination,Destination> |
RegionBroker.getDestinationMap() |
Map<ActiveMQDestination,Destination> |
AbstractRegion.getDestinationMap() |
abstract Set<ActiveMQDestination> |
DestinationFactory.getDestinations()
Returns a set of all the
ActiveMQDestination
objects that the persistence store is aware exist. |
Set<ActiveMQDestination> |
DestinationFactoryImpl.getDestinations() |
Set<ActiveMQDestination> |
RegionBroker.getDurableDestinations() |
protected Set<ActiveMQDestination> |
QueueRegion.getInactiveDestinations() |
protected Set<ActiveMQDestination> |
TopicRegion.getInactiveDestinations() |
protected Set<ActiveMQDestination> |
AbstractRegion.getInactiveDestinations() |
Modifier and Type | Method and Description |
---|---|
Destination |
Region.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean createIfTemporary)
Used to create a destination.
|
Destination |
RegionBroker.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean createIfTemp) |
Destination |
AbstractRegion.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean createIfTemporary) |
protected void |
DestinationFactoryImpl.configureQueue(Queue queue,
ActiveMQDestination destination) |
protected void |
TempQueueRegion.configureQueue(Queue queue,
ActiveMQDestination destination) |
protected void |
DestinationFactoryImpl.configureTopic(Topic topic,
ActiveMQDestination destination) |
protected void |
TopicRegion.configureTopic(Topic topic,
ActiveMQDestination destination) |
int |
Queue.copyMatchingMessages(ConnectionContext context,
MessageReferenceFilter filter,
ActiveMQDestination dest,
int maximumMessages)
Copies the messages matching the given filter up to the maximum number of
matched messages
|
int |
Queue.copyMatchingMessagesTo(ConnectionContext context,
String selector,
ActiveMQDestination dest)
Copies the messages matching the given selector
|
int |
Queue.copyMatchingMessagesTo(ConnectionContext context,
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,
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 |
AbstractTempRegion.createDestination(ConnectionContext context,
ActiveMQDestination destination) |
protected Destination |
AbstractRegion.createDestination(ConnectionContext context,
ActiveMQDestination destination) |
abstract Destination |
DestinationFactory.createDestination(ConnectionContext context,
ActiveMQDestination destination,
DestinationStatistics destinationStatistics)
Create destination implementation.
|
Destination |
DestinationFactoryImpl.createDestination(ConnectionContext context,
ActiveMQDestination destination,
DestinationStatistics destinationStatistics) |
protected javax.jms.JMSException |
RegionBroker.createUnknownDestinationTypeException(ActiveMQDestination destination) |
protected Destination |
TempTopicRegion.doCreateDestination(ConnectionContext context,
ActiveMQDestination destination) |
protected abstract Destination |
AbstractTempRegion.doCreateDestination(ConnectionContext context,
ActiveMQDestination destination) |
protected Destination |
TempQueueRegion.doCreateDestination(ConnectionContext context,
ActiveMQDestination destination) |
Set<Destination> |
Region.getDestinations(ActiveMQDestination destination)
Provide an exact or wildcard lookup of destinations in the region
|
Set<Destination> |
RegionBroker.getDestinations(ActiveMQDestination destination) |
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 |
AbstractSubscription.matches(ActiveMQDestination destination) |
boolean |
Subscription.matches(ActiveMQDestination destination)
Is the subscription interested in messages in the 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,
String selector,
ActiveMQDestination dest)
Moves the messages matching the given selector
|
int |
Queue.moveMatchingMessagesTo(ConnectionContext context,
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,
String messageId,
ActiveMQDestination dest)
Moves the message matching the given messageId
|
void |
TempTopicRegion.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
void |
Region.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout)
Used to destroy a destination.
|
void |
RegionBroker.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
void |
TempQueueRegion.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
void |
AbstractRegion.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
|
Constructor and 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) |
Modifier and Type | Method and Description |
---|---|
protected ActiveMQDestination |
IndividualDeadLetterStrategy.createDestination(Message message,
String prefix,
boolean useQueue,
Subscription subscription) |
ActiveMQDestination |
SharedDeadLetterStrategy.getDeadLetterQueue() |
ActiveMQDestination |
SharedDeadLetterStrategy.getDeadLetterQueueFor(Message message,
Subscription subscription) |
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.
|
Modifier and Type | Method and Description |
---|---|
Message[] |
LastImageSubscriptionRecoveryPolicy.browse(ActiveMQDestination destination) |
Message[] |
TimedSubscriptionRecoveryPolicy.browse(ActiveMQDestination destination) |
Message[] |
NoSubscriptionRecoveryPolicy.browse(ActiveMQDestination dest) |
Message[] |
QueryBasedSubscriptionRecoveryPolicy.browse(ActiveMQDestination dest) |
Message[] |
SubscriptionRecoveryPolicy.browse(ActiveMQDestination dest) |
Message[] |
FixedCountSubscriptionRecoveryPolicy.browse(ActiveMQDestination destination) |
Message[] |
FixedSizedSubscriptionRecoveryPolicy.browse(ActiveMQDestination destination) |
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) |
Constructor and Description |
---|
SimpleDispatchSelector(ActiveMQDestination destination) |
Modifier and Type | Method and Description |
---|---|
ActiveMQDestination |
FilteredDestination.getDestination() |
protected ActiveMQDestination |
MirroredQueue.getMirrorTopic(ActiveMQDestination original) |
protected ActiveMQDestination |
VirtualTopicInterceptor.getQueueConsumersWildcard(ActiveMQDestination original) |
ActiveMQDestination |
CompositeTopic.getVirtualDestination() |
ActiveMQDestination |
CompositeQueue.getVirtualDestination() |
ActiveMQDestination |
VirtualDestination.getVirtualDestination()
Returns the virtual destination
|
ActiveMQDestination |
VirtualTopic.getVirtualDestination() |
Modifier and Type | Method and Description |
---|---|
void |
VirtualDestinationInterceptor.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) |
void |
CompositeDestination.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
|
Modifier and Type | Method and Description |
---|---|
protected void |
SchedulerBroker.sendScheduledJob(ConnectionContext context,
Job job,
ActiveMQDestination replyTo) |
Modifier and Type | Method and Description |
---|---|
protected ActiveMQDestination |
DestinationPathSeparatorBroker.convertDestination(ActiveMQDestination destination) |
ActiveMQDestination[] |
LoggingBrokerPlugin.getDestinations() |
Modifier and Type | Method and Description |
---|---|
Set<ActiveMQDestination> |
LoggingBrokerPlugin.getDurableDestinations() |
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Method and Description |
---|---|
Destination |
DestinationDotFileInterceptor.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean create) |
void |
DestinationDotFileInterceptor.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
Modifier and Type | Class and Description |
---|---|
class |
ActiveMQQueue |
class |
ActiveMQTempDestination |
class |
ActiveMQTempQueue |
class |
ActiveMQTempTopic |
class |
ActiveMQTopic |
Modifier and Type | Field and Description |
---|---|
protected ActiveMQDestination[] |
ActiveMQDestination.compositeDestinations |
protected ActiveMQDestination |
ProducerInfo.destination |
protected ActiveMQDestination |
ConsumerControl.destination |
protected ActiveMQDestination |
DestinationInfo.destination |
protected ActiveMQDestination |
SubscriptionInfo.destination |
protected ActiveMQDestination |
MessagePull.destination |
protected ActiveMQDestination |
MessageDispatch.destination |
protected ActiveMQDestination |
Message.destination |
protected ActiveMQDestination |
ConsumerInfo.destination |
protected ActiveMQDestination |
MessageAck.destination |
protected ActiveMQDestination |
MessageDispatchNotification.destination |
protected ActiveMQDestination |
Message.originalDestination |
protected ActiveMQDestination |
Message.replyTo |
protected ActiveMQDestination |
SubscriptionInfo.subscribedDestination |
Modifier and Type | Method and Description |
---|---|
ActiveMQDestination |
ActiveMQDestination.createDestination(String name) |
static ActiveMQDestination |
ActiveMQDestination.createDestination(String name,
byte defaultType) |
ActiveMQDestination[] |
ActiveMQDestination.getCompositeDestinations() |
ActiveMQDestination |
JournalQueueAck.getDestination() |
ActiveMQDestination |
ProducerInfo.getDestination() |
ActiveMQDestination |
ConsumerControl.getDestination() |
ActiveMQDestination |
DestinationInfo.getDestination() |
ActiveMQDestination |
SubscriptionInfo.getDestination()
This is the a resolved destination that the subscription is receiving
messages from.
|
ActiveMQDestination |
MessagePull.getDestination() |
ActiveMQDestination |
MessageDispatch.getDestination() |
ActiveMQDestination |
Message.getDestination() |
ActiveMQDestination |
ConsumerInfo.getDestination()
The destination that the consumer is interested in receiving messages
from.
|
ActiveMQDestination |
JournalTopicAck.getDestination() |
ActiveMQDestination |
MessageAck.getDestination() |
ActiveMQDestination |
MessageDispatchNotification.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) |
ActiveMQDestination |
UnresolvedDestinationTransformer.transform(javax.jms.Destination dest) |
ActiveMQDestination |
DefaultUnresolvedDestinationTransformer.transform(javax.jms.Destination dest) |
ActiveMQDestination |
UnresolvedDestinationTransformer.transform(String dest) |
ActiveMQDestination |
DefaultUnresolvedDestinationTransformer.transform(String dest) |
Modifier and Type | Method and Description |
---|---|
static int |
ActiveMQDestination.compare(ActiveMQDestination destination,
ActiveMQDestination destination2) |
void |
ActiveMQDestination.setCompositeDestinations(ActiveMQDestination[] destinations) |
void |
JournalQueueAck.setDestination(ActiveMQDestination destination) |
void |
ProducerInfo.setDestination(ActiveMQDestination destination) |
void |
ConsumerControl.setDestination(ActiveMQDestination destination) |
void |
DestinationInfo.setDestination(ActiveMQDestination destination) |
void |
SubscriptionInfo.setDestination(ActiveMQDestination destination) |
void |
MessagePull.setDestination(ActiveMQDestination destination) |
void |
MessageDispatch.setDestination(ActiveMQDestination destination) |
void |
Message.setDestination(ActiveMQDestination destination) |
void |
ConsumerInfo.setDestination(ActiveMQDestination destination) |
void |
JournalTopicAck.setDestination(ActiveMQDestination destination) |
void |
MessageAck.setDestination(ActiveMQDestination destination) |
void |
MessageDispatchNotification.setDestination(ActiveMQDestination destination) |
void |
Message.setOriginalDestination(ActiveMQDestination destination) |
void |
Message.setReplyTo(ActiveMQDestination replyTo) |
void |
SubscriptionInfo.setSubscribedDestination(ActiveMQDestination subscribedDestination) |
Constructor and Description |
---|
ActiveMQDestination(ActiveMQDestination[] composites) |
DestinationInfo(ConnectionId connectionId,
byte operationType,
ActiveMQDestination destination) |
Modifier and Type | Class and Description |
---|---|
class |
AnyDestination |
Modifier and Type | Field and Description |
---|---|
protected ActiveMQDestination |
MessageEvaluationContext.destination |
Modifier and Type | Method and Description |
---|---|
ActiveMQDestination |
MessageEvaluationContext.getDestination() |
ActiveMQDestination |
DestinationMapEntry.getDestination() |
Modifier and Type | Method and Description |
---|---|
Object |
DestinationMap.chooseValue(ActiveMQDestination destination)
Returns the value which matches the given destination or null if there is
no matching value.
|
protected Set |
DestinationMap.findWildcardMatches(ActiveMQDestination key) |
Set |
DestinationMap.get(ActiveMQDestination key)
Looks up the value(s) matching the given Destination key.
|
static String[] |
DestinationPath.getDestinationPaths(ActiveMQDestination destination) |
protected DestinationMapNode |
DestinationMap.getRootNode(ActiveMQDestination key)
Returns the root node for the given destination type
|
boolean |
PrefixDestinationFilter.matches(ActiveMQDestination destination) |
abstract boolean |
DestinationFilter.matches(ActiveMQDestination destination) |
boolean |
CompositeDestinationFilter.matches(ActiveMQDestination destination) |
boolean |
SimpleDestinationFilter.matches(ActiveMQDestination destination) |
boolean |
WildcardDestinationFilter.matches(ActiveMQDestination destination) |
static DestinationFilter |
DestinationFilter.parseFilter(ActiveMQDestination destination) |
void |
DestinationMap.put(ActiveMQDestination key,
Object value) |
void |
DestinationMap.remove(ActiveMQDestination key,
Object value)
Removes the value from the associated destination
|
Set |
DestinationMap.removeAll(ActiveMQDestination key) |
void |
MessageEvaluationContext.setDestination(ActiveMQDestination destination) |
void |
DestinationMapEntry.setDestination(ActiveMQDestination destination) |
Constructor and Description |
---|
AnyDestination(ActiveMQDestination[] destinations) |
CompositeDestinationFilter(ActiveMQDestination destination) |
SimpleDestinationFilter(ActiveMQDestination destination) |
Modifier and Type | Method and Description |
---|---|
Message[] |
MessageList.browse(ActiveMQDestination destination) |
Message[] |
SimpleMessageList.browse(ActiveMQDestination destination) |
Message[] |
DestinationBasedMessageList.browse(ActiveMQDestination destination) |
List |
MessageList.getMessages(ActiveMQDestination destination)
Returns the current list of MessageReference objects for the given subscription
|
List<MessageReference> |
SimpleMessageList.getMessages(ActiveMQDestination destination) |
List<MessageReference> |
DestinationBasedMessageList.getMessages(ActiveMQDestination destination) |
Modifier and Type | Field and Description |
---|---|
protected ActiveMQDestination[] |
DemandForwardingBridgeSupport.durableDestinations |
protected ActiveMQDestination[] |
DemandForwardingBridgeSupport.dynamicallyIncludedDestinations |
protected ActiveMQDestination[] |
DemandForwardingBridgeSupport.excludedDestinations |
protected ActiveMQDestination[] |
DemandForwardingBridgeSupport.staticallyIncludedDestinations |
Modifier and Type | Method and Description |
---|---|
ActiveMQDestination[] |
DemandForwardingBridgeSupport.getDurableDestinations() |
ActiveMQDestination[] |
DemandForwardingBridgeSupport.getDynamicallyIncludedDestinations() |
ActiveMQDestination[] |
DemandForwardingBridgeSupport.getExcludedDestinations() |
ActiveMQDestination[] |
DemandForwardingBridgeSupport.getStaticallyIncludedDestinations() |
Modifier and Type | Method and Description |
---|---|
List<ActiveMQDestination> |
NetworkBridgeConfiguration.getDynamicallyIncludedDestinations() |
List<ActiveMQDestination> |
NetworkConnector.getDynamicallyIncludedDestinations() |
List<ActiveMQDestination> |
NetworkBridgeConfiguration.getExcludedDestinations() |
List<ActiveMQDestination> |
NetworkConnector.getExcludedDestinations() |
List<ActiveMQDestination> |
NetworkBridgeConfiguration.getStaticallyIncludedDestinations() |
List<ActiveMQDestination> |
NetworkConnector.getStaticallyIncludedDestinations() |
Modifier and Type | Method and Description |
---|---|
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 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) |
Modifier and Type | Method and Description |
---|---|
void |
NetworkConnector.setDurableDestinations(Set<ActiveMQDestination> durableDestinations) |
void |
NetworkBridgeConfiguration.setDynamicallyIncludedDestinations(List<ActiveMQDestination> dynamicallyIncludedDestinations) |
void |
NetworkConnector.setDynamicallyIncludedDestinations(List<ActiveMQDestination> dynamicallyIncludedDestinations) |
void |
NetworkBridgeConfiguration.setExcludedDestinations(List<ActiveMQDestination> excludedDestinations) |
void |
NetworkConnector.setExcludedDestinations(List<ActiveMQDestination> excludedDestinations) |
void |
NetworkBridgeConfiguration.setStaticallyIncludedDestinations(List<ActiveMQDestination> staticallyIncludedDestinations) |
void |
NetworkConnector.setStaticallyIncludedDestinations(List<ActiveMQDestination> staticallyIncludedDestinations) |
Modifier and Type | Method and Description |
---|---|
protected void |
StatisticsBroker.sendStats(ConnectionContext context,
ActiveMQMapMessage msg,
ActiveMQDestination replyTo) |
protected void |
StatisticsBroker.sendSubStats(ConnectionContext context,
ObjectName[] subscribers,
ActiveMQDestination replyTo) |
Modifier and Type | Method and Description |
---|---|
protected ActiveMQDestination |
CachedLDAPAuthorizationMap.formatDestination(String destinationName,
String destinationType) |
Modifier and Type | Method and Description |
---|---|
ConcurrentHashMap<ActiveMQDestination,ActiveMQDestination> |
SecurityContext.getAuthorizedReadDests() |
ConcurrentHashMap<ActiveMQDestination,ActiveMQDestination> |
SecurityContext.getAuthorizedReadDests() |
ConcurrentHashMap<ActiveMQDestination,ActiveMQDestination> |
SecurityContext.getAuthorizedWriteDests() |
ConcurrentHashMap<ActiveMQDestination,ActiveMQDestination> |
SecurityContext.getAuthorizedWriteDests() |
Modifier and Type | Method and Description |
---|---|
Destination |
AuthorizationBroker.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean create) |
Set |
DefaultAuthorizationMap.get(ActiveMQDestination key)
Looks up the value(s) matching the given Destination key.
|
protected Set<GroupPrincipal> |
LDAPAuthorizationMap.getACLs(ActiveMQDestination destination,
String roleBase,
String roleAttribute) |
Set<Object> |
DefaultAuthorizationMap.getAdminACLs(ActiveMQDestination destination) |
Set<GroupPrincipal> |
LDAPAuthorizationMap.getAdminACLs(ActiveMQDestination destination) |
Set<Object> |
SimpleAuthorizationMap.getAdminACLs(ActiveMQDestination destination) |
Set<?> |
AuthorizationMap.getAdminACLs(ActiveMQDestination destination)
Returns the set of all ACLs capable of administering the given
destination
|
protected Set<AuthorizationEntry> |
CachedLDAPAuthorizationMap.getAllEntries(ActiveMQDestination destination) |
protected Set<AuthorizationEntry> |
DefaultAuthorizationMap.getAllEntries(ActiveMQDestination destination) |
protected Set<GroupPrincipal> |
LDAPAuthorizationMap.getCompositeACLs(ActiveMQDestination destination,
String roleBase,
String roleAttribute) |
AuthorizationEntry |
DefaultAuthorizationMap.getEntryFor(ActiveMQDestination destination) |
Set<Object> |
DefaultAuthorizationMap.getReadACLs(ActiveMQDestination destination) |
Set<GroupPrincipal> |
LDAPAuthorizationMap.getReadACLs(ActiveMQDestination destination) |
Set<Object> |
SimpleAuthorizationMap.getReadACLs(ActiveMQDestination destination) |
Set<?> |
AuthorizationMap.getReadACLs(ActiveMQDestination destination)
Returns the set of all ACLs capable of reading (consuming from) the given
destination
|
Set<Object> |
DefaultAuthorizationMap.getWriteACLs(ActiveMQDestination destination) |
Set<GroupPrincipal> |
LDAPAuthorizationMap.getWriteACLs(ActiveMQDestination destination) |
Set<Object> |
SimpleAuthorizationMap.getWriteACLs(ActiveMQDestination destination) |
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) |
Modifier and Type | Method and Description |
---|---|
void |
ConnectionState.removeTempDestination(ActiveMQDestination destination) |
Modifier and Type | Field and Description |
---|---|
protected ActiveMQDestination |
AbstractMessageStore.destination |
Modifier and Type | Method and Description |
---|---|
ActiveMQDestination |
AbstractMessageStore.getDestination() |
ActiveMQDestination |
MessageStore.getDestination()
The destination that the message store is holding messages for.
|
ActiveMQDestination |
ProxyMessageStore.getDestination() |
ActiveMQDestination |
ProxyTopicMessageStore.getDestination() |
Modifier and Type | Method and Description |
---|---|
Set<ActiveMQDestination> |
PersistenceAdapter.getDestinations()
Returns a set of all the
ActiveMQDestination
objects that the persistence store is aware exist. |
Constructor and Description |
---|
AbstractMessageStore(ActiveMQDestination destination) |
Modifier and Type | Method and Description |
---|---|
Set<ActiveMQDestination> |
AMQPersistenceAdapter.getDestinations() |
Constructor and Description |
---|
AMQMessageStore(AMQPersistenceAdapter adapter,
ReferenceStore referenceStore,
ActiveMQDestination destination) |
AMQTxOperation(byte operationType,
ActiveMQDestination destination,
Object data,
Location location) |
Modifier and Type | Method and Description |
---|---|
Set<ActiveMQDestination> |
JDBCAdapter.doGetDestinations(TransactionContext c) |
Set<ActiveMQDestination> |
JDBCPersistenceAdapter.getDestinations() |
Modifier and Type | Method and Description |
---|---|
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,
String messageRef) |
void |
JDBCAdapter.doDeleteSubscription(TransactionContext c,
ActiveMQDestination destinationName,
String clientId,
String subscriptionName) |
SubscriptionInfo[] |
JDBCAdapter.doGetAllSubscriptions(TransactionContext c,
ActiveMQDestination destination) |
int |
JDBCAdapter.doGetDurableSubscriberMessageCount(TransactionContext c,
ActiveMQDestination destination,
String clientId,
String subscriptionName,
boolean isPrioritizeMessages) |
long |
JDBCAdapter.doGetLastAckedDurableSubscriberMessageId(TransactionContext c,
ActiveMQDestination destination,
String clientId,
String subscriberName) |
int |
JDBCAdapter.doGetMessageCount(TransactionContext c,
ActiveMQDestination destination) |
SubscriptionInfo |
JDBCAdapter.doGetSubscriberEntry(TransactionContext c,
ActiveMQDestination destination,
String clientId,
String subscriptionName) |
void |
JDBCAdapter.doRecordDestination(TransactionContext c,
ActiveMQDestination destination) |
void |
JDBCAdapter.doRecover(TransactionContext c,
ActiveMQDestination destination,
JDBCMessageRecoveryListener listener) |
void |
JDBCAdapter.doRecoverNextMessages(TransactionContext c,
ActiveMQDestination destination,
long nextSeq,
long priority,
int maxReturned,
boolean isPrioritizeMessages,
JDBCMessageRecoveryListener listener) |
void |
JDBCAdapter.doRecoverNextMessages(TransactionContext c,
ActiveMQDestination destination,
String clientId,
String subscriptionName,
long seq,
long priority,
int maxReturned,
JDBCMessageRecoveryListener listener) |
void |
JDBCAdapter.doRecoverNextMessagesWithPriority(TransactionContext c,
ActiveMQDestination destination,
String clientId,
String subscriptionName,
long seq,
long priority,
int maxReturned,
JDBCMessageRecoveryListener listener) |
void |
JDBCAdapter.doRecoverSubscription(TransactionContext c,
ActiveMQDestination destination,
String clientId,
String subscriptionName,
JDBCMessageRecoveryListener listener) |
void |
JDBCAdapter.doRemoveAllMessages(TransactionContext c,
ActiveMQDestination destinationName) |
void |
JDBCAdapter.doSetLastAck(TransactionContext c,
ActiveMQDestination destination,
String clientId,
String subscriptionName,
long seq,
long prio) |
void |
JDBCAdapter.doSetLastAckWithPriority(TransactionContext c,
ActiveMQDestination destination,
String clientId,
String subscriptionName,
long re,
long re1) |
long[] |
JDBCAdapter.getStoreSequenceId(TransactionContext c,
ActiveMQDestination destination,
MessageId messageID) |
Constructor and Description |
---|
JDBCMessageStore(JDBCPersistenceAdapter persistenceAdapter,
JDBCAdapter adapter,
WireFormat wireFormat,
ActiveMQDestination destination,
ActiveMQMessageAudit audit) |
Modifier and Type | Method and Description |
---|---|
Set<ActiveMQDestination> |
DefaultJDBCAdapter.doGetDestinations(TransactionContext c) |
Modifier and Type | Method and Description |
---|---|
void |
BlobJDBCAdapter.doAddMessage(TransactionContext c,
long sequence,
MessageId messageID,
ActiveMQDestination destination,
byte[] data,
long expiration,
byte priority) |
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,
String messageRef) |
void |
DefaultJDBCAdapter.doDeleteSubscription(TransactionContext c,
ActiveMQDestination destination,
String clientId,
String subscriptionName) |
SubscriptionInfo[] |
DefaultJDBCAdapter.doGetAllSubscriptions(TransactionContext c,
ActiveMQDestination destination) |
int |
DefaultJDBCAdapter.doGetDurableSubscriberMessageCount(TransactionContext c,
ActiveMQDestination destination,
String clientId,
String subscriptionName,
boolean isPrioritizedMessages) |
long |
DefaultJDBCAdapter.doGetLastAckedDurableSubscriberMessageId(TransactionContext c,
ActiveMQDestination destination,
String clientId,
String subscriberName) |
int |
DefaultJDBCAdapter.doGetMessageCount(TransactionContext c,
ActiveMQDestination destination) |
byte[] |
DefaultJDBCAdapter.doGetNextDurableSubscriberMessageStatement(TransactionContext c,
ActiveMQDestination destination,
String clientId,
String subscriberName) |
SubscriptionInfo |
DefaultJDBCAdapter.doGetSubscriberEntry(TransactionContext c,
ActiveMQDestination destination,
String clientId,
String subscriptionName) |
void |
DefaultJDBCAdapter.doRecordDestination(TransactionContext c,
ActiveMQDestination destination) |
void |
DefaultJDBCAdapter.doRecover(TransactionContext c,
ActiveMQDestination destination,
JDBCMessageRecoveryListener listener) |
void |
DefaultJDBCAdapter.doRecoverNextMessages(TransactionContext c,
ActiveMQDestination destination,
long nextSeq,
long priority,
int maxReturned,
boolean isPrioritizedMessages,
JDBCMessageRecoveryListener listener) |
void |
DefaultJDBCAdapter.doRecoverNextMessages(TransactionContext c,
ActiveMQDestination destination,
String clientId,
String subscriptionName,
long seq,
long priority,
int maxReturned,
JDBCMessageRecoveryListener listener) |
void |
DefaultJDBCAdapter.doRecoverNextMessagesWithPriority(TransactionContext c,
ActiveMQDestination destination,
String clientId,
String subscriptionName,
long seq,
long priority,
int maxReturned,
JDBCMessageRecoveryListener listener) |
void |
DefaultJDBCAdapter.doRecoverSubscription(TransactionContext c,
ActiveMQDestination destination,
String clientId,
String subscriptionName,
JDBCMessageRecoveryListener listener) |
void |
DefaultJDBCAdapter.doRemoveAllMessages(TransactionContext c,
ActiveMQDestination destinationName) |
void |
DefaultJDBCAdapter.doSetLastAck(TransactionContext c,
ActiveMQDestination destination,
String clientId,
String subscriptionName,
long seq,
long priority) |
void |
DefaultJDBCAdapter.doSetLastAckWithPriority(TransactionContext c,
ActiveMQDestination destination,
String clientId,
String subscriptionName,
long seq,
long prio) |
long[] |
DefaultJDBCAdapter.getStoreSequenceId(TransactionContext c,
ActiveMQDestination destination,
MessageId messageID) |
Modifier and Type | Method and Description |
---|---|
Set<ActiveMQDestination> |
JournalPersistenceAdapter.getDestinations() |
Constructor and Description |
---|
JournalMessageStore(JournalPersistenceAdapter adapter,
MessageStore checkpointStore,
ActiveMQDestination destination) |
Modifier and Type | Field and Description |
---|---|
protected ConcurrentHashMap<ActiveMQDestination,MessageStore> |
KahaPersistenceAdapter.messageStores |
Modifier and Type | Method and Description |
---|---|
Set<ActiveMQDestination> |
KahaPersistenceAdapter.getDestinations() |
Constructor and Description |
---|
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<String,SubscriptionInfo> subsContainer,
ActiveMQDestination destination) |
KahaTopicReferenceStore(Store store,
KahaReferenceStoreAdapter adapter,
MapContainer<MessageId,ReferenceRecord> messageContainer,
ListContainer<TopicSubAck> ackContainer,
MapContainer<String,SubscriptionInfo> subsContainer,
ActiveMQDestination destination) |
Modifier and Type | Method and Description |
---|---|
ActiveMQDestination |
KahaDBStore.KahaDBMessageStore.getDestination() |
ActiveMQDestination |
TempKahaDBStore.KahaDBMessageStore.getDestination() |
Modifier and Type | Method and Description |
---|---|
Set<ActiveMQDestination> |
KahaDBStore.getDestinations() |
Set<ActiveMQDestination> |
TempKahaDBStore.getDestinations() |
Set<ActiveMQDestination> |
MultiKahaDBPersistenceAdapter.getDestinations() |
Set<ActiveMQDestination> |
KahaDBPersistenceAdapter.getDestinations() |
Constructor and Description |
---|
FilteredKahaDBPersistenceAdapter(ActiveMQDestination destination,
KahaDBPersistenceAdapter adapter) |
KahaDBMessageStore(ActiveMQDestination destination) |
KahaDBMessageStore(ActiveMQDestination destination) |
Modifier and Type | Method and Description |
---|---|
Set<ActiveMQDestination> |
MemoryPersistenceAdapter.getDestinations() |
Constructor and 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) |
Modifier and Type | Method and Description |
---|---|
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) |
Copyright © 2005–2015 The Apache Software Foundation. All rights reserved.