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.command |
Command objects used via the Command Pattern to communicate among nodes
|
org.apache.activemq.filter |
Filter implementations for wildcards & JMS selectors
|
org.apache.activemq.memory.list | |
org.apache.activemq.network |
Support for federated networks of brokers.
|
org.apache.activemq.plugin | |
org.apache.activemq.ra |
JCA managed connections and resource adapters for working with ActiveMQ
|
org.apache.activemq.security |
Plugable Security Adapter framework along with default implementations such as the JAAS implementation.
|
org.apache.activemq.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.kahadb | |
org.apache.activemq.store.memory |
VM based implementation of message persistence
|
org.apache.activemq.transport.mqtt |
A Broker side implementation of the MQTT 3.1 protocol - see http://mqtt.org/
|
org.apache.activemq.transport.mqtt.strategy | |
org.apache.activemq.transport.stomp |
An implementation of the Stomp protocol which is a simple wire protocol for writing clients for ActiveMQ in different
languages like Ruby, Python, PHP, C etc.
|
org.apache.activemq.util |
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 |
---|
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) |
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 ConcurrentMap<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[] |
BrokerFilter.getDestinations() |
ActiveMQDestination[] |
Broker.getDestinations() |
ActiveMQDestination[] |
EmptyBroker.getDestinations() |
ActiveMQDestination[] |
BrokerService.getDestinations() |
ActiveMQDestination[] |
ErrorBroker.getDestinations() |
Modifier and Type | Method and Description |
---|---|
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 |
ErrorBroker.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean flag) |
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
|
void |
EmptyBroker.fastProducer(ConnectionContext context,
ProducerInfo producerInfo,
ActiveMQDestination destination) |
void |
ErrorBroker.fastProducer(ConnectionContext context,
ProducerInfo producerInfo,
ActiveMQDestination destination) |
Destination |
BrokerService.getDestination(ActiveMQDestination destination)
Looks up and lazily creates if necessary the destination for the given
JMS name
|
Map<ActiveMQDestination,Destination> |
BrokerFilter.getDestinationMap(ActiveMQDestination destination) |
Map<ActiveMQDestination,Destination> |
Broker.getDestinationMap(ActiveMQDestination destination)
return a reference destination map of a region based on the destination type
|
Map<ActiveMQDestination,Destination> |
EmptyBroker.getDestinationMap(ActiveMQDestination destination) |
Map<ActiveMQDestination,Destination> |
ErrorBroker.getDestinationMap(ActiveMQDestination destination) |
Set<Destination> |
BrokerFilter.getDestinations(ActiveMQDestination destination) |
Set<Destination> |
EmptyBroker.getDestinations(ActiveMQDestination destination) |
Set<Destination> |
ErrorBroker.getDestinations(ActiveMQDestination destination) |
void |
BrokerService.removeDestination(ActiveMQDestination destination) |
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 |
ErrorBroker.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 |
---|---|
void |
BrokerService.startNetworkConnector(NetworkConnector connector,
Set<ActiveMQDestination> durableDestinations,
ThreadPoolExecutor networkConnectorStartExecutor) |
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 |
ManagedQueueRegion.createDestination(ConnectionContext context,
ActiveMQDestination destination) |
protected Destination |
ManagedTopicRegion.createDestination(ConnectionContext context,
ActiveMQDestination destination) |
protected Destination |
ManagedTempQueueRegion.createDestination(ConnectionContext context,
ActiveMQDestination destination) |
protected Destination |
ManagedTempTopicRegion.createDestination(ConnectionContext context,
ActiveMQDestination destination) |
static ObjectName |
BrokerMBeanSupport.createDestinationName(ObjectName brokerObjectName,
ActiveMQDestination destination) |
static ObjectName |
BrokerMBeanSupport.createDestinationName(String brokerObjectName,
ActiveMQDestination destination) |
static ObjectName |
BrokerMBeanSupport.createNetworkInBoundDestinationObjectName(ObjectName networkName,
ActiveMQDestination destination) |
static ObjectName |
BrokerMBeanSupport.createNetworkOutBoundDestinationObjectName(ObjectName networkName,
ActiveMQDestination destination) |
boolean |
SubscriptionView.matchesDestination(ActiveMQDestination destination)
Return true if this subscription matches the given 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 |
ManagedTopicRegion.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
void |
ManagedTempQueueRegion.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
void |
ManagedTempTopicRegion.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
void |
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 |
SubscriptionRecovery.getActiveMQDestination() |
ActiveMQDestination |
Queue.getActiveMQDestination() |
ActiveMQDestination |
BaseDestination.getActiveMQDestination() |
ActiveMQDestination |
DestinationFilter.getActiveMQDestination() |
ActiveMQDestination |
AbstractSubscription.getActiveMQDestination() |
ActiveMQDestination[] |
RegionBroker.getDestinations() |
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 |
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) |
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) |
Map<ActiveMQDestination,Destination> |
RegionBroker.getDestinationMap(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
|
Region |
RegionBroker.getRegion(ActiveMQDestination destination) |
protected Destination |
AbstractRegion.lookup(ConnectionContext context,
ActiveMQDestination destination,
boolean createTemporary) |
boolean |
AbstractSubscription.matches(ActiveMQDestination destination) |
boolean |
Subscription.matches(ActiveMQDestination destination)
Is the subscription interested in messages in the destination?
|
int |
Queue.moveMatchingMessagesTo(ConnectionContext context,
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 |
TempQueueRegion.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
void |
RegionBroker.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
void |
AbstractRegion.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
protected void |
DestinationFilter.send(ProducerBrokerExchange context,
Message message,
ActiveMQDestination destination)
Sends a message to the given destination which may be a wildcard
|
protected void |
AbstractRegion.updateRegionDestCounts(ActiveMQDestination destination,
int count)
Updates the counts in RegionStatistics based on whether or not the destination
is an Advisory Destination or not
|
protected void |
AbstractRegion.validateMaxDestinations(ActiveMQDestination destination)
This method checks whether or not the destination can be created based on
PolicyEntry.getMaxDestinations() , if it has been set. |
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,
String suffix,
boolean useQueue,
Subscription subscription) |
ActiveMQDestination |
SharedDeadLetterStrategy.getDeadLetterQueue() |
ActiveMQDestination |
SharedDeadLetterStrategy.getDeadLetterQueueFor(Message message,
Subscription subscription) |
ActiveMQDestination |
DeadLetterStrategy.getDeadLetterQueueFor(Message message,
Subscription subscription)
Returns the dead letter queue for the given message and subscription.
|
ActiveMQDestination |
IndividualDeadLetterStrategy.getDeadLetterQueueFor(Message message,
Subscription subscription) |
Modifier and Type | Method and Description |
---|---|
Message[] |
SubscriptionRecoveryPolicy.browse(ActiveMQDestination dest) |
Message[] |
LastImageSubscriptionRecoveryPolicy.browse(ActiveMQDestination destination) |
Message[] |
NoSubscriptionRecoveryPolicy.browse(ActiveMQDestination dest) |
Message[] |
TimedSubscriptionRecoveryPolicy.browse(ActiveMQDestination destination) |
Message[] |
RetainedMessageSubscriptionRecoveryPolicy.browse(ActiveMQDestination destination) |
Message[] |
FixedSizedSubscriptionRecoveryPolicy.browse(ActiveMQDestination destination) |
Message[] |
QueryBasedSubscriptionRecoveryPolicy.browse(ActiveMQDestination dest) |
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) |
void |
SharedDeadLetterStrategy.setDeadLetterQueue(ActiveMQDestination deadLetterQueue) |
Constructor and Description |
---|
SimpleDispatchSelector(ActiveMQDestination destination) |
Modifier and Type | Method and Description |
---|---|
ActiveMQDestination |
FilteredDestination.getDestination() |
ActiveMQDestination |
VirtualTopic.getMappedDestinations() |
ActiveMQDestination |
VirtualDestination.getMappedDestinations()
Returns mapped destination(s)
|
ActiveMQDestination |
CompositeDestination.getMappedDestinations() |
protected ActiveMQDestination |
MirroredQueue.getMirrorTopic(ActiveMQDestination original) |
protected ActiveMQDestination |
VirtualTopicInterceptor.getQueueConsumersWildcard(ActiveMQDestination original) |
ActiveMQDestination |
VirtualTopic.getVirtualDestination() |
ActiveMQDestination |
CompositeTopic.getVirtualDestination() |
ActiveMQDestination |
VirtualDestination.getVirtualDestination()
Returns the virtual destination
|
ActiveMQDestination |
CompositeQueue.getVirtualDestination() |
Modifier and Type | Method and Description |
---|---|
void |
VirtualTopic.create(Broker broker,
ConnectionContext context,
ActiveMQDestination destination) |
void |
MirroredQueue.create(Broker broker,
ConnectionContext context,
ActiveMQDestination destination) |
void |
VirtualDestinationInterceptor.create(Broker broker,
ConnectionContext context,
ActiveMQDestination destination) |
void |
CompositeDestination.create(Broker broker,
ConnectionContext context,
ActiveMQDestination destination) |
protected ActiveMQDestination |
MirroredQueue.getMirrorTopic(ActiveMQDestination original) |
protected ActiveMQDestination |
VirtualTopicInterceptor.getQueueConsumersWildcard(ActiveMQDestination original) |
protected void |
VirtualTopicInterceptor.send(ProducerBrokerExchange context,
Message message,
ActiveMQDestination destination) |
void |
FilteredDestination.setDestination(ActiveMQDestination destination)
The destination to send messages to if they match the filter
|
Constructor and Description |
---|
MappedQueueFilter(ActiveMQDestination virtualDestination,
Destination destination) |
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 |
LoggingBrokerPlugin.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean create) |
Destination |
DestinationPathSeparatorBroker.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean createIfTemporary) |
Destination |
DestinationsPlugin.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean createIfTemporary) |
protected ActiveMQDestination |
DestinationPathSeparatorBroker.convertDestination(ActiveMQDestination destination) |
void |
LoggingBrokerPlugin.fastProducer(ConnectionContext context,
ProducerInfo producerInfo,
ActiveMQDestination destination) |
void |
LoggingBrokerPlugin.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
void |
UDPTraceBrokerPlugin.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
void |
DestinationPathSeparatorBroker.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
void |
DestinationsPlugin.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
Modifier and Type | Method and Description |
---|---|
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 | 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 |
DestinationInfo.destination |
protected ActiveMQDestination |
ConsumerInfo.destination |
protected ActiveMQDestination |
ProducerInfo.destination |
protected ActiveMQDestination |
MessageDispatch.destination |
protected ActiveMQDestination |
Message.destination |
protected ActiveMQDestination |
SubscriptionInfo.destination |
protected ActiveMQDestination |
MessagePull.destination |
protected ActiveMQDestination |
MessageAck.destination |
protected ActiveMQDestination |
ConsumerControl.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 |
DestinationInfo.getDestination() |
ActiveMQDestination |
JournalQueueAck.getDestination() |
ActiveMQDestination |
ConsumerInfo.getDestination()
The destination that the consumer is interested in receiving messages
from.
|
ActiveMQDestination |
ProducerInfo.getDestination() |
ActiveMQDestination |
MessageDispatch.getDestination() |
ActiveMQDestination |
Message.getDestination() |
ActiveMQDestination |
SubscriptionInfo.getDestination()
This is the a resolved destination that the subscription is receiving
messages from.
|
ActiveMQDestination |
MessagePull.getDestination() |
ActiveMQDestination |
MessageAck.getDestination() |
ActiveMQDestination |
JournalTopicAck.getDestination() |
ActiveMQDestination |
ConsumerControl.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) |
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 |
DestinationMapEntry.destination |
protected ActiveMQDestination |
MessageEvaluationContext.destination |
Modifier and Type | Method and Description |
---|---|
ActiveMQDestination |
DestinationMapEntry.getDestination() |
ActiveMQDestination |
MessageEvaluationContext.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) |
protected Set |
DestinationMap.findWildcardMatches(ActiveMQDestination key,
boolean deep) |
Set |
DestinationMap.get(ActiveMQDestination key)
Looks up the value(s) matching the given Destination key.
|
static String[] |
DestinationPath.getDestinationPaths(ActiveMQDestination destination) |
protected DestinationMapNode |
DestinationMap.getRootNode(ActiveMQDestination key)
Returns the root node for the given destination type
|
boolean |
WildcardDestinationFilter.matches(ActiveMQDestination destination) |
boolean |
SimpleDestinationFilter.matches(ActiveMQDestination destination) |
abstract boolean |
DestinationFilter.matches(ActiveMQDestination destination) |
boolean |
CompositeDestinationFilter.matches(ActiveMQDestination destination) |
boolean |
PrefixDestinationFilter.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 |
DestinationMapEntry.setDestination(ActiveMQDestination destination) |
void |
MessageEvaluationContext.setDestination(ActiveMQDestination destination) |
Constructor and Description |
---|
AnyDestination(ActiveMQDestination[] destinations) |
CompositeDestinationFilter(ActiveMQDestination destination) |
SimpleDestinationFilter(ActiveMQDestination destination) |
Modifier and Type | Method and Description |
---|---|
Message[] |
DestinationBasedMessageList.browse(ActiveMQDestination destination) |
Message[] |
SimpleMessageList.browse(ActiveMQDestination destination) |
Message[] |
MessageList.browse(ActiveMQDestination destination) |
List<MessageReference> |
DestinationBasedMessageList.getMessages(ActiveMQDestination destination) |
List<MessageReference> |
SimpleMessageList.getMessages(ActiveMQDestination destination) |
List |
MessageList.getMessages(ActiveMQDestination destination)
Returns the current list of MessageReference objects for the given subscription
|
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 List<ActiveMQDestination> |
NetworkBridgeConfiguration.dynamicallyIncludedDestinations |
protected List<ActiveMQDestination> |
NetworkBridgeConfiguration.excludedDestinations |
protected List<ActiveMQDestination> |
NetworkBridgeConfiguration.staticallyIncludedDestinations |
Modifier and Type | Method and Description |
---|---|
ActiveMQDestination[] |
DemandForwardingBridgeSupport.getDurableDestinations() |
static ActiveMQDestination[] |
NetworkConnector.getDurableTopicDestinations(Set<ActiveMQDestination> durableDestinations) |
ActiveMQDestination[] |
DemandForwardingBridgeSupport.getDynamicallyIncludedDestinations() |
ActiveMQDestination[] |
DemandForwardingBridgeSupport.getExcludedDestinations() |
ActiveMQDestination[] |
DemandForwardingBridgeSupport.getStaticallyIncludedDestinations() |
Modifier and Type | Method and Description |
---|---|
Set<ActiveMQDestination> |
NetworkConnector.getDurableDestinations() |
List<ActiveMQDestination> |
NetworkBridgeConfiguration.getDynamicallyIncludedDestinations() |
List<ActiveMQDestination> |
NetworkBridgeConfiguration.getExcludedDestinations() |
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,
String subscriptionName) |
protected boolean |
DurableConduitBridge.doesConsumerExist(ActiveMQDestination dest) |
protected Collection<Subscription> |
DemandForwardingBridgeSupport.getRegionSubscriptions(ActiveMQDestination dest) |
protected String |
DurableConduitBridge.getSubscriberName(ActiveMQDestination dest) |
protected boolean |
DemandForwardingBridgeSupport.isPermissableDestination(ActiveMQDestination destination) |
protected boolean |
DemandForwardingBridgeSupport.isPermissableDestination(ActiveMQDestination destination,
boolean allowTemporary) |
void |
DemandForwardingBridgeSupport.setDurableDestinations(ActiveMQDestination[] durableDestinations) |
void |
DemandForwardingBridgeSupport.setDynamicallyIncludedDestinations(ActiveMQDestination[] dynamicallyIncludedDestinations) |
void |
DemandForwardingBridgeSupport.setExcludedDestinations(ActiveMQDestination[] excludedDestinations) |
void |
DemandForwardingBridgeSupport.setStaticallyIncludedDestinations(ActiveMQDestination[] staticallyIncludedDestinations) |
Modifier and Type | Method and Description |
---|---|
static ActiveMQDestination[] |
NetworkConnector.getDurableTopicDestinations(Set<ActiveMQDestination> durableDestinations) |
void |
NetworkConnector.setDurableDestinations(Set<ActiveMQDestination> durableDestinations) |
void |
NetworkBridgeConfiguration.setDynamicallyIncludedDestinations(List<ActiveMQDestination> dynamicallyIncludedDestinations) |
void |
NetworkBridgeConfiguration.setExcludedDestinations(List<ActiveMQDestination> excludedDestinations) |
void |
NetworkBridgeConfiguration.setStaticallyIncludedDestinations(List<ActiveMQDestination> staticallyIncludedDestinations) |
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 |
---|---|
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 Map<ActiveMQDestination,AuthorizationEntry> |
SimpleCachedLDAPAuthorizationMap.entries |
Modifier and Type | Method and Description |
---|---|
protected ActiveMQDestination |
SimpleCachedLDAPAuthorizationMap.formatDestination(LdapName dn,
SimpleCachedLDAPAuthorizationMap.DestinationType destinationType)
Parses a DN into the equivalent
ActiveMQDestination . |
protected ActiveMQDestination |
SimpleCachedLDAPAuthorizationMap.formatDestination(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 |
---|---|
ConcurrentMap<ActiveMQDestination,ActiveMQDestination> |
SecurityContext.getAuthorizedWriteDests() |
ConcurrentMap<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) |
void |
AuthorizationDestinationInterceptor.create(Broker broker,
ConnectionContext context,
ActiveMQDestination destination) |
Set |
DefaultAuthorizationMap.get(ActiveMQDestination key)
Looks up the value(s) matching the given Destination key.
|
protected Set<GroupPrincipal> |
LDAPAuthorizationMap.getACLs(ActiveMQDestination destination,
String roleBase,
String roleAttribute) |
Set<Object> |
DefaultAuthorizationMap.getAdminACLs(ActiveMQDestination destination) |
Set<Object> |
SimpleAuthorizationMap.getAdminACLs(ActiveMQDestination destination) |
Set<GroupPrincipal> |
LDAPAuthorizationMap.getAdminACLs(ActiveMQDestination destination) |
Set<?> |
AuthorizationMap.getAdminACLs(ActiveMQDestination destination)
Returns the set of all ACLs capable of administering the given
destination
|
Set<Object> |
SimpleCachedLDAPAuthorizationMap.getAdminACLs(ActiveMQDestination destination)
Provides synchronized access to the admin ACLs for the destinations as
AuthorizationEntry
is not setup for concurrent access. |
protected Set<AuthorizationEntry> |
DefaultAuthorizationMap.getAllEntries(ActiveMQDestination destination) |
protected Set<GroupPrincipal> |
LDAPAuthorizationMap.getCompositeACLs(ActiveMQDestination destination,
String roleBase,
String roleAttribute) |
AuthorizationEntry |
DefaultAuthorizationMap.getEntryFor(ActiveMQDestination destination) |
Set<Object> |
DefaultAuthorizationMap.getReadACLs(ActiveMQDestination destination) |
Set<Object> |
SimpleAuthorizationMap.getReadACLs(ActiveMQDestination destination) |
Set<GroupPrincipal> |
LDAPAuthorizationMap.getReadACLs(ActiveMQDestination destination) |
Set<?> |
AuthorizationMap.getReadACLs(ActiveMQDestination destination)
Returns the set of all ACLs capable of reading (consuming from) the given
destination
|
Set<Object> |
SimpleCachedLDAPAuthorizationMap.getReadACLs(ActiveMQDestination destination)
Provides synchronized access to the read ACLs for the destinations as
AuthorizationEntry is not setup for
concurrent access. |
Set<Object> |
DefaultAuthorizationMap.getWriteACLs(ActiveMQDestination destination) |
Set<Object> |
SimpleAuthorizationMap.getWriteACLs(ActiveMQDestination destination) |
Set<GroupPrincipal> |
LDAPAuthorizationMap.getWriteACLs(ActiveMQDestination destination) |
Set<?> |
AuthorizationMap.getWriteACLs(ActiveMQDestination destination)
Returns the set of all ACLs capable of writing to the given destination
|
Set<Object> |
SimpleCachedLDAPAuthorizationMap.getWriteACLs(ActiveMQDestination destination)
Provides synchronized access to the write ACLs for the destinations as
AuthorizationEntry is not setup
for concurrent access. |
void |
AbstractAuthenticationBroker.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
void |
JaasDualAuthenticationBroker.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
void |
AuthorizationBroker.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 Collection<org.apache.shiro.authz.Permission> |
DestinationActionPermissionResolver.createPermissions(ActiveMQDestination dest,
String verb) |
protected String |
DestinationActionPermissionResolver.createPermissionString(ActiveMQDestination dest,
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,
String verb) |
Modifier and Type | Method and Description |
---|---|
ConcurrentMap<ActiveMQDestination,ActiveMQDestination> |
SubjectSecurityContext.getAuthorizedWriteDests() |
ConcurrentMap<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 |
AbstractMessageStore.getDestination() |
ActiveMQDestination |
ProxyMessageStore.getDestination() |
ActiveMQDestination |
MessageStore.getDestination()
The destination that the message store is holding messages for.
|
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. |
Modifier and Type | Method and Description |
---|---|
boolean |
PersistenceAdapterSupport.DestinationMatcher.matches(ActiveMQDestination destination)
Given a Destination object, return true if the destination matches some defined
search criteria, false otherwise.
|
Constructor and Description |
---|
AbstractMessageStore(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() |
Modifier and Type | Method and Description |
---|---|
static String |
MultiKahaDBPersistenceAdapter.nameFromDestinationFilter(ActiveMQDestination destination) |
Constructor and Description |
---|
FilteredKahaDBPersistenceAdapter(FilteredKahaDBPersistenceAdapter template,
ActiveMQDestination destination,
PersistenceAdapter 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 |
---|---|
ActiveMQDestination |
MQTTSubscription.getDestination()
The real
ActiveMQDestination that this subscription is assigned. |
Modifier and Type | Method and Description |
---|---|
ActiveMQDestination |
AbstractMQTTSubscriptionStrategy.onSend(String topicName) |
ActiveMQDestination |
MQTTVirtualTopicSubscriptionStrategy.onSend(String topicName) |
ActiveMQDestination |
MQTTSubscriptionStrategy.onSend(String topicName)
Intercepts PUBLISH operations from the client and allows the strategy to map the
target destination so that the send operation will land in the destinations that
this strategy has mapped the incoming subscribe requests to.
|
Modifier and Type | Method and Description |
---|---|
boolean |
AbstractMQTTSubscriptionStrategy.isControlTopic(ActiveMQDestination destination) |
boolean |
MQTTVirtualTopicSubscriptionStrategy.isControlTopic(ActiveMQDestination destination) |
boolean |
MQTTSubscriptionStrategy.isControlTopic(ActiveMQDestination destination)
Allows the protocol handler to interrogate an destination name to determine if it
is equivalent to the MQTT control topic (starts with $).
|
String |
AbstractMQTTSubscriptionStrategy.onSend(ActiveMQDestination destination) |
String |
MQTTVirtualTopicSubscriptionStrategy.onSend(ActiveMQDestination destination) |
String |
MQTTSubscriptionStrategy.onSend(ActiveMQDestination destination)
Intercepts send operations from the broker and allows the strategy to map the
target topic name so that the client sees a valid Topic name.
|
Modifier and Type | Field and Description |
---|---|
protected ActiveMQDestination |
StompSubscription.destination |
Modifier and Type | Method and Description |
---|---|
ActiveMQDestination |
FrameTranslator.convertDestination(ProtocolConverter converter,
String name,
boolean forceFallback) |
ActiveMQDestination |
LegacyFrameTranslator.convertDestination(ProtocolConverter converter,
String name,
boolean forceFallback) |
ActiveMQDestination |
ProtocolConverter.createTempDestination(String name,
boolean topic) |
ActiveMQDestination |
StompSubscription.getDestination() |
Modifier and Type | Method and Description |
---|---|
protected FrameTranslator |
ProtocolConverter.findTranslator(String header,
ActiveMQDestination destination,
boolean advisory) |
String |
ProtocolConverter.getCreatedTempDestinationName(ActiveMQDestination destination) |
void |
StompSubscription.setDestination(ActiveMQDestination destination) |
Modifier and Type | Method and Description |
---|---|
static ActiveMQDestination |
NetworkBridgeUtils.findMatchingDestination(ActiveMQDestination[] dests,
ActiveMQDestination destination) |
Modifier and Type | Method and Description |
---|---|
static List<ActiveMQDestination> |
StringToListOfActiveMQDestinationConverter.convertToActiveMQDestination(Object value) |
Modifier and Type | Method and Description |
---|---|
static void |
BrokerSupport.doResend(ConnectionContext context,
Message originalMessage,
ActiveMQDestination deadLetterDestination,
boolean copy) |
static ActiveMQDestination |
NetworkBridgeUtils.findMatchingDestination(ActiveMQDestination[] dests,
ActiveMQDestination destination) |
static ActiveMQDestination |
NetworkBridgeUtils.findMatchingDestination(ActiveMQDestination[] dests,
ActiveMQDestination destination) |
static boolean |
NetworkBridgeUtils.isDestForcedDurable(ActiveMQDestination destination) |
static boolean |
NetworkBridgeUtils.isForcedDurable(ConsumerInfo info,
ActiveMQDestination[] dynamicallyIncludedDestinations,
ActiveMQDestination[] staticallyIncludedDestinations) |
static boolean |
NetworkBridgeUtils.isForcedDurable(ConsumerInfo info,
ActiveMQDestination[] dynamicallyIncludedDestinations,
ActiveMQDestination[] staticallyIncludedDestinations) |
static boolean |
NetworkBridgeUtils.matchesDestinations(ActiveMQDestination[] dests,
ActiveMQDestination destination) |
static boolean |
NetworkBridgeUtils.matchesDestinations(ActiveMQDestination[] dests,
ActiveMQDestination destination) |
static boolean |
NetworkBridgeUtils.matchesNetworkConfig(NetworkBridgeConfiguration config,
ActiveMQDestination destination) |
static void |
BrokerSupport.resend(ConnectionContext context,
Message originalMessage,
ActiveMQDestination deadLetterDestination) |
static void |
BrokerSupport.resendNoCopy(ConnectionContext context,
Message originalMessage,
ActiveMQDestination deadLetterDestination) |
Modifier and Type | Method and Description |
---|---|
static boolean |
NetworkBridgeUtils.isForcedDurable(ConsumerInfo info,
List<ActiveMQDestination> dynamicallyIncludedDestinations) |
Copyright © 2005–2017. All rights reserved.