Package | Description |
---|---|
org.apache.activemq |
The core JMS client API implementation classes.
|
org.apache.activemq.advisory |
Support for JMS Advisory messages as well as some helper listeners to listen to the clients, producers and consumers available.
|
org.apache.activemq.broker |
The core classes for the ActiveMQ Message Broker and its connectors.
|
org.apache.activemq.broker.inteceptor |
MessageInteceptor malarky
|
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 |
The Message Scheduler for delayed (or scheduled) message delivery
|
org.apache.activemq.broker.util |
Some utility Broker Plugins
|
org.apache.activemq.broker.view |
Broker Plugins for visualising the current system
|
org.apache.activemq.camel.component.broker | |
org.apache.activemq.camel.converter |
Defines the Type Converters for working
with JMS and ActiveMQ with Camel
Enterprise Integration Patterns
|
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.partition | |
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.shiro.authz | |
org.apache.activemq.shiro.subject | |
org.apache.activemq.state | |
org.apache.activemq.store |
The APIs which need to be implemented for persistent message stores for durable messaging
|
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.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 | |
org.apache.activemq.web |
Web Connectors so that messages can be sent via HTTP POST or read via
HTTP POST or GET as well as support for web streaming to web browser or
JavaScript clients.
|
org.apache.activemq.web.controller |
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,
java.lang.String selector,
boolean noLocal,
java.lang.String name,
int prefetch,
long timeout)
Deprecated.
|
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)
Deprecated.
|
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) |
Modifier and Type | Field and Description |
---|---|
protected java.util.concurrent.ConcurrentHashMap<ActiveMQDestination,DestinationInfo> |
AdvisoryBroker.destinations |
Modifier and Type | Method and Description |
---|---|
ActiveMQDestination |
DestinationEvent.getDestination() |
Modifier and Type | Method and Description |
---|---|
java.util.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[] |
MutableBrokerFilter.getDestinations() |
ActiveMQDestination[] |
ErrorBroker.getDestinations() |
ActiveMQDestination[] |
EmptyBroker.getDestinations() |
ActiveMQDestination[] |
BrokerService.getDestinations() |
ActiveMQDestination[] |
BrokerFilter.getDestinations() |
ActiveMQDestination[] |
Broker.getDestinations() |
Modifier and Type | Method and Description |
---|---|
java.util.Map<ActiveMQDestination,Destination> |
MutableBrokerFilter.getDestinationMap() |
java.util.Map<ActiveMQDestination,Destination> |
ErrorBroker.getDestinationMap() |
java.util.Map<ActiveMQDestination,Destination> |
EmptyBroker.getDestinationMap() |
java.util.Map<ActiveMQDestination,Destination> |
BrokerFilter.getDestinationMap() |
java.util.Set<ActiveMQDestination> |
MutableBrokerFilter.getDurableDestinations() |
java.util.Set<ActiveMQDestination> |
ErrorBroker.getDurableDestinations() |
java.util.Set<ActiveMQDestination> |
EmptyBroker.getDurableDestinations() |
java.util.Set<ActiveMQDestination> |
BrokerFilter.getDurableDestinations() |
java.util.Set<ActiveMQDestination> |
Broker.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 |
EmptyBroker.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean flag) |
Destination |
BrokerFilter.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean createIfTemporary) |
Destination |
BrokerBroadcaster.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean createIfTemporary) |
void |
MutableBrokerFilter.fastProducer(ConnectionContext context,
ProducerInfo producerInfo,
ActiveMQDestination destination) |
void |
ErrorBroker.fastProducer(ConnectionContext context,
ProducerInfo producerInfo,
ActiveMQDestination destination) |
void |
EmptyBroker.fastProducer(ConnectionContext context,
ProducerInfo producerInfo,
ActiveMQDestination destination) |
void |
BrokerFilter.fastProducer(ConnectionContext context,
ProducerInfo producerInfo,
ActiveMQDestination destination) |
void |
Broker.fastProducer(ConnectionContext context,
ProducerInfo producerInfo,
ActiveMQDestination destination)
Called to notify a producer is too fast
|
Destination |
BrokerService.getDestination(ActiveMQDestination destination)
Looks up and lazily creates if necessary the destination for the given
JMS name
|
java.util.Set |
MutableBrokerFilter.getDestinations(ActiveMQDestination destination) |
java.util.Set |
ErrorBroker.getDestinations(ActiveMQDestination destination) |
java.util.Set |
EmptyBroker.getDestinations(ActiveMQDestination destination) |
java.util.Set<Destination> |
BrokerFilter.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 |
EmptyBroker.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
void |
BrokerFilter.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) |
Modifier and Type | Method and Description |
---|---|
MessageInterceptor |
MessageInterceptorRegistry.addMessageInterceptor(ActiveMQDestination activeMQDestination,
MessageInterceptor messageInterceptor) |
void |
MessageInterceptorRegistry.removeMessageInterceptor(ActiveMQDestination activeMQDestination,
MessageInterceptor interceptor) |
Modifier and Type | Field and Description |
---|---|
protected ActiveMQDestination |
ProducerView.lastUsedDestination |
Modifier and Type | Method and Description |
---|---|
protected Destination |
ManagedTopicRegion.createDestination(ConnectionContext context,
ActiveMQDestination destination) |
protected Destination |
ManagedTempTopicRegion.createDestination(ConnectionContext context,
ActiveMQDestination destination) |
protected Destination |
ManagedTempQueueRegion.createDestination(ConnectionContext context,
ActiveMQDestination destination) |
protected Destination |
ManagedQueueRegion.createDestination(ConnectionContext context,
ActiveMQDestination destination) |
static javax.management.ObjectName |
BrokerMBeanSupport.createDestinationName(javax.management.ObjectName brokerObjectName,
ActiveMQDestination destination) |
static javax.management.ObjectName |
BrokerMBeanSupport.createDestinationName(java.lang.String brokerObjectName,
ActiveMQDestination destination) |
static javax.management.ObjectName |
BrokerMBeanSupport.createNetworkInBoundDestinationObjectName(javax.management.ObjectName networkName,
ActiveMQDestination destination) |
static javax.management.ObjectName |
BrokerMBeanSupport.createNetworkOutBoundDestinationObjectName(javax.management.ObjectName networkName,
ActiveMQDestination destination) |
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) |
protected void |
ManagedRegionBroker.registerProducer(javax.management.ObjectName key,
ActiveMQDestination dest,
ProducerView view) |
void |
ManagedTopicRegion.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 |
ManagedQueueRegion.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 java.util.Map<ActiveMQDestination,Destination> |
AbstractRegion.destinations |
Modifier and Type | Method and Description |
---|---|
ActiveMQDestination |
SubscriptionRecovery.getActiveMQDestination() |
ActiveMQDestination |
Queue.getActiveMQDestination() |
ActiveMQDestination |
DestinationFilter.getActiveMQDestination() |
ActiveMQDestination |
Destination.getActiveMQDestination() |
ActiveMQDestination |
BaseDestination.getActiveMQDestination() |
ActiveMQDestination |
AbstractSubscription.getActiveMQDestination() |
ActiveMQDestination[] |
RegionBroker.getDestinations() |
Modifier and Type | Method and Description |
---|---|
java.util.Map<ActiveMQDestination,Destination> |
RegionBroker.getDestinationMap() |
java.util.Map<ActiveMQDestination,Destination> |
Region.getDestinationMap()
Returns a reference to the concurrent hash map that holds known destinations, do not modify
|
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> |
QueueRegion.getInactiveDestinations() |
protected java.util.Set<ActiveMQDestination> |
AbstractRegion.getInactiveDestinations() |
Modifier and Type | Method and Description |
---|---|
Destination |
RegionBroker.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean createIfTemp) |
Destination |
Region.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean createIfTemporary)
Used to create a destination.
|
Destination |
AbstractRegion.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean createIfTemporary) |
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 |
DestinationInterceptor.create(Broker broker,
ConnectionContext context,
ActiveMQDestination destination) |
void |
CompositeDestinationInterceptor.create(Broker broker,
ConnectionContext context,
ActiveMQDestination destination) |
protected Destination |
AbstractTempRegion.createDestination(ConnectionContext context,
ActiveMQDestination destination) |
protected Destination |
AbstractRegion.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) |
java.util.Set<Destination> |
RegionBroker.getDestinations(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> |
AbstractRegion.getDestinations(ActiveMQDestination destination)
Provide an exact or wildcard lookup of destinations in the region
|
protected Region |
RegionBroker.getRegion(ActiveMQDestination destination) |
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 |
TempTopicRegion.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
void |
TempQueueRegion.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
void |
RegionBroker.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
void |
Region.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout)
Used to destroy a destination.
|
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,
java.lang.String prefix,
java.lang.String suffix,
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[] |
TimedSubscriptionRecoveryPolicy.browse(ActiveMQDestination destination) |
Message[] |
SubscriptionRecoveryPolicy.browse(ActiveMQDestination dest) |
Message[] |
QueryBasedSubscriptionRecoveryPolicy.browse(ActiveMQDestination dest) |
Message[] |
NoSubscriptionRecoveryPolicy.browse(ActiveMQDestination dest) |
Message[] |
LastImageSubscriptionRecoveryPolicy.browse(ActiveMQDestination destination) |
Message[] |
FixedSizedSubscriptionRecoveryPolicy.browse(ActiveMQDestination destination) |
Message[] |
FixedCountSubscriptionRecoveryPolicy.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) |
RedeliveryPolicy |
RedeliveryPolicyMap.getEntryFor(ActiveMQDestination destination) |
boolean |
SharedDeadLetterStrategy.isDLQ(ActiveMQDestination destination) |
boolean |
IndividualDeadLetterStrategy.isDLQ(ActiveMQDestination destination) |
boolean |
DeadLetterStrategy.isDLQ(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 |
VirtualTopic.getVirtualDestination() |
ActiveMQDestination |
VirtualDestination.getVirtualDestination()
Returns the virtual destination
|
ActiveMQDestination |
CompositeTopic.getVirtualDestination() |
ActiveMQDestination |
CompositeQueue.getVirtualDestination() |
Modifier and Type | Method and Description |
---|---|
void |
VirtualTopic.create(Broker broker,
ConnectionContext context,
ActiveMQDestination destination) |
void |
VirtualDestinationInterceptor.create(Broker broker,
ConnectionContext context,
ActiveMQDestination destination) |
void |
MirroredQueue.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 |
---|---|
java.util.Set<ActiveMQDestination> |
LoggingBrokerPlugin.getDurableDestinations() |
Modifier and Type | Method and Description |
---|---|
Destination |
LoggingBrokerPlugin.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean create) |
Destination |
DestinationPathSeparatorBroker.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean createIfTemporary) |
protected ActiveMQDestination |
DestinationPathSeparatorBroker.convertDestination(ActiveMQDestination destination) |
void |
LoggingBrokerPlugin.fastProducer(ConnectionContext context,
ProducerInfo producerInfo,
ActiveMQDestination destination) |
void |
UDPTraceBrokerPlugin.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
void |
LoggingBrokerPlugin.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
void |
DestinationPathSeparatorBroker.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
Modifier and Type | Method and Description |
---|---|
java.util.Set<ActiveMQDestination> |
MessageBrokerView.getDestinations()
Retrieve a set of all Destinations be used by the Broker
|
Modifier and Type | Method and Description |
---|---|
Destination |
DestinationDotFileInterceptor.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean create) |
BrokerDestinationView |
MessageBrokerView.getDestinationView(ActiveMQDestination activeMQDestination)
Get the BrokerDestinationView associated with destination
|
void |
DestinationDotFileInterceptor.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
Modifier and Type | Method and Description |
---|---|
ActiveMQDestination |
BrokerEndpoint.getDestination() |
Constructor and Description |
---|
BrokerEndpoint(java.lang.String uri,
BrokerComponent component,
ActiveMQDestination destination,
BrokerConfiguration configuration) |
Modifier and Type | Method and Description |
---|---|
static ActiveMQDestination |
ActiveMQConverter.toDestination(java.lang.String name)
Converts a URL in ActiveMQ syntax to a destination such as to support
"queue://foo.bar" or 'topic://bar.whatnot".
|
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 |
SubscriptionInfo.destination |
protected ActiveMQDestination |
ProducerInfo.destination |
protected ActiveMQDestination |
MessagePull.destination |
protected ActiveMQDestination |
MessageDispatchNotification.destination |
protected ActiveMQDestination |
MessageDispatch.destination |
protected ActiveMQDestination |
MessageAck.destination |
protected ActiveMQDestination |
Message.destination |
protected ActiveMQDestination |
DestinationInfo.destination |
protected ActiveMQDestination |
ConsumerInfo.destination |
protected ActiveMQDestination |
ConsumerControl.destination |
protected ActiveMQDestination |
Message.originalDestination |
protected ActiveMQDestination |
Message.replyTo |
protected ActiveMQDestination |
SubscriptionInfo.subscribedDestination |
Modifier and Type | Method and Description |
---|---|
ActiveMQDestination |
ActiveMQDestination.createDestination(java.lang.String name) |
static ActiveMQDestination |
ActiveMQDestination.createDestination(java.lang.String name,
byte defaultType) |
ActiveMQDestination[] |
ActiveMQDestination.getCompositeDestinations() |
ActiveMQDestination |
SubscriptionInfo.getDestination()
This is the a resolved destination that the subscription is receiving
messages from.
|
ActiveMQDestination |
ProducerInfo.getDestination() |
ActiveMQDestination |
MessagePull.getDestination() |
ActiveMQDestination |
MessageDispatchNotification.getDestination() |
ActiveMQDestination |
MessageDispatch.getDestination() |
ActiveMQDestination |
MessageAck.getDestination() |
ActiveMQDestination |
Message.getDestination() |
ActiveMQDestination |
JournalTopicAck.getDestination() |
ActiveMQDestination |
JournalQueueAck.getDestination() |
ActiveMQDestination |
DestinationInfo.getDestination() |
ActiveMQDestination |
ConsumerInfo.getDestination()
The destination that the consumer is interested in receiving messages
from.
|
ActiveMQDestination |
ConsumerControl.getDestination() |
ActiveMQDestination |
Message.getOriginalDestination() |
ActiveMQDestination |
Message.getReplyTo() |
ActiveMQDestination |
SubscriptionInfo.getSubscribedDestination()
The destination the client originally subscribed to..
|
ActiveMQDestination |
UnresolvedDestinationTransformer.transform(javax.jms.Destination dest) |
ActiveMQDestination |
DefaultUnresolvedDestinationTransformer.transform(javax.jms.Destination dest) |
static ActiveMQDestination |
ActiveMQDestination.transform(javax.jms.Destination dest) |
ActiveMQDestination |
UnresolvedDestinationTransformer.transform(java.lang.String dest) |
ActiveMQDestination |
DefaultUnresolvedDestinationTransformer.transform(java.lang.String dest) |
Modifier and Type | Method and Description |
---|---|
static int |
ActiveMQDestination.compare(ActiveMQDestination destination,
ActiveMQDestination destination2) |
void |
ActiveMQDestination.setCompositeDestinations(ActiveMQDestination[] destinations) |
void |
SubscriptionInfo.setDestination(ActiveMQDestination destination) |
void |
ProducerInfo.setDestination(ActiveMQDestination destination) |
void |
MessagePull.setDestination(ActiveMQDestination destination) |
void |
MessageDispatchNotification.setDestination(ActiveMQDestination destination) |
void |
MessageDispatch.setDestination(ActiveMQDestination destination) |
void |
MessageAck.setDestination(ActiveMQDestination destination) |
void |
Message.setDestination(ActiveMQDestination destination) |
void |
JournalTopicAck.setDestination(ActiveMQDestination destination) |
void |
JournalQueueAck.setDestination(ActiveMQDestination destination) |
void |
DestinationInfo.setDestination(ActiveMQDestination destination) |
void |
ConsumerInfo.setDestination(ActiveMQDestination destination) |
void |
ConsumerControl.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 |
protected ActiveMQDestination |
DestinationMapEntry.destination |
Modifier and Type | Method and Description |
---|---|
ActiveMQDestination |
MessageEvaluationContext.getDestination() |
ActiveMQDestination |
DestinationMapEntry.getDestination() |
Modifier and Type | Method and Description |
---|---|
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
|
boolean |
WildcardDestinationFilter.matches(ActiveMQDestination destination) |
boolean |
SimpleDestinationFilter.matches(ActiveMQDestination destination) |
boolean |
PrefixDestinationFilter.matches(ActiveMQDestination destination) |
abstract boolean |
DestinationFilter.matches(ActiveMQDestination destination) |
boolean |
CompositeDestinationFilter.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) |
Constructor and Description |
---|
AnyDestination(ActiveMQDestination[] destinations) |
CompositeDestinationFilter(ActiveMQDestination destination) |
SimpleDestinationFilter(ActiveMQDestination destination) |
Modifier and Type | Method and Description |
---|---|
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) |
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 | Field and Description |
---|---|
protected java.util.List<ActiveMQDestination> |
NetworkBridgeConfiguration.dynamicallyIncludedDestinations |
protected java.util.List<ActiveMQDestination> |
NetworkBridgeConfiguration.excludedDestinations |
protected java.util.List<ActiveMQDestination> |
NetworkBridgeConfiguration.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 |
---|---|
java.util.Set<ActiveMQDestination> |
NetworkConnector.getDurableDestinations() |
java.util.List<ActiveMQDestination> |
NetworkBridgeConfiguration.getDynamicallyIncludedDestinations() |
java.util.List<ActiveMQDestination> |
NetworkBridgeConfiguration.getExcludedDestinations() |
java.util.List<ActiveMQDestination> |
NetworkBridgeConfiguration.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 java.util.Collection<Subscription> |
DemandForwardingBridgeSupport.getRegionSubscriptions(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) |
Modifier and Type | Method and Description |
---|---|
void |
NetworkConnector.setDurableDestinations(java.util.Set<ActiveMQDestination> durableDestinations) |
void |
NetworkBridgeConfiguration.setDynamicallyIncludedDestinations(java.util.List<ActiveMQDestination> dynamicallyIncludedDestinations) |
void |
NetworkBridgeConfiguration.setExcludedDestinations(java.util.List<ActiveMQDestination> excludedDestinations) |
void |
NetworkBridgeConfiguration.setStaticallyIncludedDestinations(java.util.List<ActiveMQDestination> staticallyIncludedDestinations) |
Modifier and Type | Method and Description |
---|---|
protected Target |
PartitionBroker.getTarget(ActiveMQDestination dest) |
Modifier and Type | Method and Description |
---|---|
Destination |
RuntimeConfigurationBroker.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean createIfTemporary) |
protected void |
StatisticsBroker.sendStats(ConnectionContext context,
ActiveMQMapMessage msg,
ActiveMQDestination replyTo) |
protected void |
StatisticsBroker.sendSubStats(ConnectionContext context,
javax.management.ObjectName[] subscribers,
ActiveMQDestination replyTo) |
Modifier and Type | Method and Description |
---|---|
ActiveMQDestination |
ActiveMQActivationSpec.createDestination() |
Modifier and Type | Method and Description |
---|---|
void |
ActiveMQActivationSpec.setActiveMQDestination(ActiveMQDestination destination)
A helper method mostly for use in Dependency Injection containers which
allows you to customize the destination and destinationType properties
from a single ActiveMQDestination POJO
|
Modifier and Type | Field and Description |
---|---|
protected java.util.Map<ActiveMQDestination,AuthorizationEntry> |
SimpleCachedLDAPAuthorizationMap.entries |
Modifier and Type | Method and Description |
---|---|
protected ActiveMQDestination |
SimpleCachedLDAPAuthorizationMap.formatDestination(javax.naming.ldap.LdapName dn,
SimpleCachedLDAPAuthorizationMap.DestinationType destinationType)
Parses a DN into the equivalent
ActiveMQDestination . |
protected ActiveMQDestination |
SimpleCachedLDAPAuthorizationMap.formatDestination(javax.naming.ldap.Rdn destinationName,
SimpleCachedLDAPAuthorizationMap.DestinationType destinationType)
Parses RDN values representing the destination name/pattern and destination type into the equivalent
ActiveMQDestination . |
Modifier and Type | Method and Description |
---|---|
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() |
Modifier and Type | Method and Description |
---|---|
Destination |
AuthorizationBroker.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean create) |
protected boolean |
AuthorizationBroker.checkDestinationAdmin(SecurityContext securityContext,
ActiveMQDestination destination) |
java.util.Set |
DefaultAuthorizationMap.get(ActiveMQDestination key)
Looks up the value(s) matching the given Destination key.
|
protected java.util.Set<GroupPrincipal> |
LDAPAuthorizationMap.getACLs(ActiveMQDestination destination,
java.lang.String roleBase,
java.lang.String roleAttribute) |
java.util.Set<java.lang.Object> |
SimpleCachedLDAPAuthorizationMap.getAdminACLs(ActiveMQDestination destination)
Provides synchronized access to the admin ACLs for the destinations as
AuthorizationEntry
is not setup for concurrent access. |
java.util.Set<java.lang.Object> |
SimpleAuthorizationMap.getAdminACLs(ActiveMQDestination destination) |
java.util.Set<GroupPrincipal> |
LDAPAuthorizationMap.getAdminACLs(ActiveMQDestination destination) |
java.util.Set<java.lang.Object> |
DefaultAuthorizationMap.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) |
protected java.util.Set<GroupPrincipal> |
LDAPAuthorizationMap.getCompositeACLs(ActiveMQDestination destination,
java.lang.String roleBase,
java.lang.String roleAttribute) |
AuthorizationEntry |
DefaultAuthorizationMap.getEntryFor(ActiveMQDestination destination) |
java.util.Set<java.lang.Object> |
SimpleCachedLDAPAuthorizationMap.getReadACLs(ActiveMQDestination destination)
Provides synchronized access to the read ACLs for the destinations as
AuthorizationEntry is not setup for
concurrent access. |
java.util.Set<java.lang.Object> |
SimpleAuthorizationMap.getReadACLs(ActiveMQDestination destination) |
java.util.Set<GroupPrincipal> |
LDAPAuthorizationMap.getReadACLs(ActiveMQDestination destination) |
java.util.Set<java.lang.Object> |
DefaultAuthorizationMap.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<java.lang.Object> |
SimpleCachedLDAPAuthorizationMap.getWriteACLs(ActiveMQDestination destination)
Provides synchronized access to the write ACLs for the destinations as
AuthorizationEntry is not setup
for concurrent access. |
java.util.Set<java.lang.Object> |
SimpleAuthorizationMap.getWriteACLs(ActiveMQDestination destination) |
java.util.Set<GroupPrincipal> |
LDAPAuthorizationMap.getWriteACLs(ActiveMQDestination destination) |
java.util.Set<java.lang.Object> |
DefaultAuthorizationMap.getWriteACLs(ActiveMQDestination destination) |
java.util.Set<?> |
AuthorizationMap.getWriteACLs(ActiveMQDestination destination)
Returns the set of all ACLs capable of writing to the given destination
|
void |
JaasDualAuthenticationBroker.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
void |
AuthorizationBroker.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
void |
AbstractAuthenticationBroker.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
Modifier and Type | Method and Description |
---|---|
ActiveMQDestination |
DestinationAction.getDestination() |
Modifier and Type | Method and Description |
---|---|
Destination |
AuthorizationFilter.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean create) |
protected java.util.Collection<org.apache.shiro.authz.Permission> |
DestinationActionPermissionResolver.createPermissions(ActiveMQDestination dest,
java.lang.String verb) |
protected java.lang.String |
DestinationActionPermissionResolver.createPermissionString(ActiveMQDestination dest,
java.lang.String verb)
Inspects the specified
destination and verb and returns a WildcardPermission -compatible
String the represents the action. |
void |
AuthorizationFilter.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
Constructor and Description |
---|
DestinationAction(ConnectionContext connectionContext,
ActiveMQDestination destination,
java.lang.String verb) |
Modifier and Type | Method and Description |
---|---|
java.util.concurrent.ConcurrentHashMap<ActiveMQDestination,ActiveMQDestination> |
SubjectSecurityContext.getAuthorizedReadDests() |
java.util.concurrent.ConcurrentHashMap<ActiveMQDestination,ActiveMQDestination> |
SubjectSecurityContext.getAuthorizedReadDests() |
java.util.concurrent.ConcurrentHashMap<ActiveMQDestination,ActiveMQDestination> |
SubjectSecurityContext.getAuthorizedWriteDests() |
java.util.concurrent.ConcurrentHashMap<ActiveMQDestination,ActiveMQDestination> |
SubjectSecurityContext.getAuthorizedWriteDests() |
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 |
ProxyTopicMessageStore.getDestination() |
ActiveMQDestination |
ProxyMessageStore.getDestination() |
ActiveMQDestination |
MessageStore.getDestination()
The destination that the message store is holding messages for.
|
ActiveMQDestination |
AbstractMessageStore.getDestination() |
Modifier and Type | Method and Description |
---|---|
java.util.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 |
---|---|
java.util.Set<ActiveMQDestination> |
JDBCAdapter.doGetDestinations(TransactionContext c) |
java.util.Set<ActiveMQDestination> |
JDBCPersistenceAdapter.getDestinations() |
Modifier and Type | Method and Description |
---|---|
void |
JDBCPersistenceAdapter.commitLastAck(ConnectionContext context,
long xidLastAck,
long priority,
ActiveMQDestination destination,
java.lang.String subName,
java.lang.String clientId) |
void |
JDBCAdapter.doAddMessage(TransactionContext c,
long sequence,
MessageId messageID,
ActiveMQDestination destination,
byte[] data,
long expiration,
byte priority,
XATransactionId xid) |
void |
JDBCAdapter.doAddMessageReference(TransactionContext c,
long sequence,
MessageId messageId,
ActiveMQDestination destination,
long expirationTime,
java.lang.String messageRef) |
void |
JDBCAdapter.doClearLastAck(TransactionContext c,
ActiveMQDestination destination,
byte priority,
java.lang.String subId,
java.lang.String subName) |
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.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,
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,
XATransactionId xid,
java.lang.String clientId,
java.lang.String subscriptionName,
long seq,
long prio) |
void |
JDBCAdapter.doSetLastAckWithPriority(TransactionContext c,
ActiveMQDestination destination,
XATransactionId xid,
java.lang.String clientId,
java.lang.String subscriptionName,
long re,
long re1) |
long[] |
JDBCTopicMessageStore.getCachedStoreSequenceId(TransactionContext transactionContext,
ActiveMQDestination destination,
MessageId messageId) |
long[] |
JDBCAdapter.getStoreSequenceId(TransactionContext c,
ActiveMQDestination destination,
MessageId messageID) |
void |
JdbcMemoryTransactionStore.recoverLastAck(byte[] encodedXid,
ActiveMQDestination destination,
java.lang.String subName,
java.lang.String clientId) |
void |
JDBCPersistenceAdapter.rollbackLastAck(ConnectionContext context,
byte priority,
ActiveMQDestination destination,
java.lang.String subName,
java.lang.String clientId) |
Constructor and Description |
---|
JDBCMessageStore(JDBCPersistenceAdapter persistenceAdapter,
JDBCAdapter adapter,
WireFormat wireFormat,
ActiveMQDestination destination,
ActiveMQMessageAudit audit) |
Modifier and Type | Method and Description |
---|---|
java.util.Set<ActiveMQDestination> |
DefaultJDBCAdapter.doGetDestinations(TransactionContext c) |
Modifier and Type | Method and Description |
---|---|
void |
DefaultJDBCAdapter.doAddMessage(TransactionContext c,
long sequence,
MessageId messageID,
ActiveMQDestination destination,
byte[] data,
long expiration,
byte priority,
XATransactionId xid)
A non null xid indicated the op is part of 2pc prepare, so ops are flagged pending outcome
|
void |
BlobJDBCAdapter.doAddMessage(TransactionContext c,
long sequence,
MessageId messageID,
ActiveMQDestination destination,
byte[] data,
long expiration,
byte priority,
XATransactionId xid) |
void |
DefaultJDBCAdapter.doAddMessageReference(TransactionContext c,
long sequence,
MessageId messageID,
ActiveMQDestination destination,
long expirationTime,
java.lang.String messageRef) |
void |
DefaultJDBCAdapter.doClearLastAck(TransactionContext c,
ActiveMQDestination destination,
byte priority,
java.lang.String clientId,
java.lang.String subName) |
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) |
SubscriptionInfo |
DefaultJDBCAdapter.doGetSubscriberEntry(TransactionContext c,
ActiveMQDestination destination,
java.lang.String clientId,
java.lang.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,
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,
XATransactionId xid,
java.lang.String clientId,
java.lang.String subscriptionName,
long seq,
long priority) |
void |
DefaultJDBCAdapter.doSetLastAckWithPriority(TransactionContext c,
ActiveMQDestination destination,
XATransactionId xid,
java.lang.String clientId,
java.lang.String subscriptionName,
long seq,
long priority) |
long[] |
DefaultJDBCAdapter.getStoreSequenceId(TransactionContext c,
ActiveMQDestination destination,
MessageId messageID) |
Modifier and Type | Method and Description |
---|---|
java.util.Set<ActiveMQDestination> |
JournalPersistenceAdapter.getDestinations() |
Constructor and Description |
---|
JournalMessageStore(JournalPersistenceAdapter adapter,
MessageStore checkpointStore,
ActiveMQDestination destination) |
Modifier and Type | Method and Description |
---|---|
ActiveMQDestination |
TempKahaDBStore.KahaDBMessageStore.getDestination() |
ActiveMQDestination |
KahaDBStore.KahaDBMessageStore.getDestination() |
Modifier and Type | Method and Description |
---|---|
java.util.Set<ActiveMQDestination> |
TempKahaDBStore.getDestinations() |
java.util.Set<ActiveMQDestination> |
MultiKahaDBPersistenceAdapter.getDestinations() |
java.util.Set<ActiveMQDestination> |
KahaDBStore.getDestinations() |
java.util.Set<ActiveMQDestination> |
KahaDBPersistenceAdapter.getDestinations() |
Constructor and Description |
---|
FilteredKahaDBPersistenceAdapter(ActiveMQDestination destination,
PersistenceAdapter adapter) |
KahaDBStore.KahaDBMessageStore(ActiveMQDestination destination) |
TempKahaDBStore.KahaDBMessageStore(ActiveMQDestination destination) |
Modifier and Type | Method and Description |
---|---|
java.util.Set<ActiveMQDestination> |
MemoryPersistenceAdapter.getDestinations() |
Constructor and Description |
---|
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) |
Modifier and Type | Field and Description |
---|---|
protected ActiveMQDestination |
StompSubscription.destination |
Modifier and Type | Method and Description |
---|---|
ActiveMQDestination |
LegacyFrameTranslator.convertDestination(ProtocolConverter converter,
java.lang.String name,
boolean forceFallback) |
ActiveMQDestination |
FrameTranslator.convertDestination(ProtocolConverter converter,
java.lang.String name,
boolean forceFallback) |
ActiveMQDestination |
ProtocolConverter.createTempDestination(java.lang.String name,
boolean topic) |
ActiveMQDestination |
StompSubscription.getDestination() |
Modifier and Type | Method and Description |
---|---|
protected FrameTranslator |
ProtocolConverter.findTranslator(java.lang.String header,
ActiveMQDestination destination) |
java.lang.String |
ProtocolConverter.getCreatedTempDestinationName(ActiveMQDestination destination) |
void |
StompSubscription.setDestination(ActiveMQDestination destination) |
Modifier and Type | Method and Description |
---|---|
static java.util.List<ActiveMQDestination> |
StringToListOfActiveMQDestinationConverter.convertToActiveMQDestination(java.lang.Object value) |
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) |
Modifier and Type | Method and Description |
---|---|
protected ActiveMQDestination |
DestinationFacade.createDestination() |
Modifier and Type | Method and Description |
---|---|
void |
RemoteJMXBrokerFacade.purgeQueue(ActiveMQDestination destination) |
void |
LocalBrokerFacade.purgeQueue(ActiveMQDestination destination) |
void |
BrokerFacade.purgeQueue(ActiveMQDestination destination)
Purges the given destination
|
Modifier and Type | Method and Description |
---|---|
protected void |
SendMessage.sendMessages(javax.servlet.http.HttpServletRequest request,
WebClient client,
ActiveMQDestination dest) |
Copyright © 2005-2014 Red Hat, Inc.. All Rights Reserved.