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.cluster | |
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.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.network |
Support for federated networks of brokers.
|
org.apache.activemq.plugin | |
org.apache.activemq.security |
Plugable Security Adapter framework along with default implementations such as the JAAS implementation.
|
org.apache.activemq.shiro.authz | |
org.apache.activemq.state | |
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 | Field and Description |
---|---|
protected ConsumerInfo |
ActiveMQMessageConsumer.info |
Modifier and Type | Method and Description |
---|---|
ConsumerInfo |
ActiveMQConnectionConsumer.getConsumerInfo() |
Constructor and Description |
---|
ActiveMQConnectionConsumer(ActiveMQConnection theConnection,
javax.jms.ServerSessionPool theSessionPool,
ConsumerInfo theConsumerInfo)
Create a ConnectionConsumer
|
Modifier and Type | Field and Description |
---|---|
protected ConcurrentMap<org.apache.activemq.advisory.AdvisoryBroker.VirtualConsumerPair,ConsumerInfo> |
AdvisoryBroker.brokerConsumerDests
This is a map to track unique demand for the existence of a virtual destination so we make sure
we don't send duplicate advisories.
|
protected Map<ConsumerId,ConsumerInfo> |
AdvisoryBroker.consumers |
protected ConcurrentMap<ConsumerInfo,VirtualDestination> |
AdvisoryBroker.virtualDestinationConsumers
This is a map to track all consumers that exist on the virtual destination so that we can fire
an advisory later when they go away to remove the demand.
|
Modifier and Type | Method and Description |
---|---|
ConsumerInfo |
ConsumerStartedEvent.getConsumerInfo() |
Modifier and Type | Method and Description |
---|---|
Collection<ConsumerInfo> |
AdvisoryBroker.getAdvisoryConsumers() |
ConcurrentMap<ConsumerInfo,VirtualDestination> |
AdvisoryBroker.getVirtualDestinationConsumers() |
Modifier and Type | Method and Description |
---|---|
Subscription |
AdvisoryBroker.addConsumer(ConnectionContext context,
ConsumerInfo info) |
void |
AdvisoryBroker.removeConsumer(ConnectionContext context,
ConsumerInfo info) |
Constructor and Description |
---|
ConsumerStartedEvent(ConsumerEventSource source,
ActiveMQDestination destination,
ConsumerInfo consumerInfo,
int count) |
Modifier and Type | Method and Description |
---|---|
Subscription |
ConnectionSplitBroker.addConsumer(ConnectionContext context,
ConsumerInfo info) |
void |
ConnectionSplitBroker.removeConsumer(ConnectionContext context,
ConsumerInfo info) |
Modifier and Type | Method and Description |
---|---|
protected ConsumerInfo |
SubscriptionView.getConsumerInfo() |
protected ConsumerInfo |
InactiveDurableSubscriptionView.getConsumerInfo() |
Modifier and Type | Method and Description |
---|---|
Subscription |
ManagedRegionBroker.addConsumer(ConnectionContext context,
ConsumerInfo info) |
protected Subscription |
ManagedTopicRegion.createSubscription(ConnectionContext context,
ConsumerInfo info) |
protected Subscription |
ManagedQueueRegion.createSubscription(ConnectionContext context,
ConsumerInfo info) |
protected Subscription |
ManagedTempTopicRegion.createSubscription(ConnectionContext context,
ConsumerInfo info) |
protected Subscription |
ManagedTempQueueRegion.createSubscription(ConnectionContext context,
ConsumerInfo info) |
static ObjectName |
BrokerMBeanSupport.createSubscriptionName(ObjectName brokerObjectName,
String connectionClientId,
ConsumerInfo info) |
static ObjectName |
BrokerMBeanSupport.createSubscriptionName(String brokerObjectName,
String connectionClientId,
ConsumerInfo info) |
protected void |
ManagedRegionBroker.registerSubscription(ObjectName key,
ConsumerInfo info,
SubscriptionKey subscriptionKey,
SubscriptionView view) |
void |
ManagedRegionBroker.removeConsumer(ConnectionContext context,
ConsumerInfo info) |
Modifier and Type | Field and Description |
---|---|
protected ConsumerInfo |
AbstractSubscription.info |
Modifier and Type | Method and Description |
---|---|
ConsumerInfo |
TopicRegion.createInactiveConsumerInfo(SubscriptionInfo info) |
ConsumerInfo |
Subscription.getConsumerInfo()
The ConsumerInfo object that created the subscription.
|
ConsumerInfo |
AbstractSubscription.getConsumerInfo() |
ConsumerInfo |
AbstractSubscription.getInfo() |
Constructor and Description |
---|
AbstractSubscription(Broker broker,
ConnectionContext context,
ConsumerInfo info) |
DurableTopicSubscription(Broker broker,
SystemUsage usageManager,
ConnectionContext context,
ConsumerInfo info,
boolean keepDurableSubsActive) |
PrefetchSubscription(Broker broker,
SystemUsage usageManager,
ConnectionContext context,
ConsumerInfo info) |
PrefetchSubscription(Broker broker,
SystemUsage usageManager,
ConnectionContext context,
ConsumerInfo info,
PendingMessageCursor cursor) |
QueueBrowserSubscription(Broker broker,
SystemUsage usageManager,
ConnectionContext context,
ConsumerInfo info) |
QueueSubscription(Broker broker,
SystemUsage usageManager,
ConnectionContext context,
ConsumerInfo info) |
TopicSubscription(Broker broker,
ConnectionContext context,
ConsumerInfo info,
SystemUsage usageManager) |
Modifier and Type | Method and Description |
---|---|
Subscription |
UDPTraceBrokerPlugin.addConsumer(ConnectionContext context,
ConsumerInfo info) |
Subscription |
DestinationPathSeparatorBroker.addConsumer(ConnectionContext context,
ConsumerInfo info) |
Subscription |
LoggingBrokerPlugin.addConsumer(ConnectionContext context,
ConsumerInfo info) |
void |
UDPTraceBrokerPlugin.removeConsumer(ConnectionContext context,
ConsumerInfo info) |
void |
DestinationPathSeparatorBroker.removeConsumer(ConnectionContext context,
ConsumerInfo info) |
void |
LoggingBrokerPlugin.removeConsumer(ConnectionContext context,
ConsumerInfo info) |
Modifier and Type | Method and Description |
---|---|
Subscription |
ConnectionDotFileInterceptor.addConsumer(ConnectionContext context,
ConsumerInfo info) |
void |
ConnectionDotFileInterceptor.removeConsumer(ConnectionContext context,
ConsumerInfo info) |
Modifier and Type | Method and Description |
---|---|
ConsumerInfo |
ConsumerInfo.copy() |
ConsumerInfo[] |
BrokerSubscriptionInfo.getSubscriptionInfos() |
Modifier and Type | Method and Description |
---|---|
void |
MessagePull.configure(ConsumerInfo info)
Configures a message pull from the consumer information
|
void |
ConsumerInfo.copy(ConsumerInfo info) |
void |
BrokerSubscriptionInfo.setSubscriptionInfos(ConsumerInfo[] subscriptionInfos) |
Constructor and Description |
---|
NetworkBridgeFilter(ConsumerInfo consumerInfo,
BrokerId networkBrokerId,
int messageTTL,
int consumerTTL) |
Modifier and Type | Field and Description |
---|---|
protected ConsumerInfo |
DemandForwardingBridgeSupport.demandConsumerInfo |
Modifier and Type | Method and Description |
---|---|
ConsumerInfo |
DemandSubscription.getLocalInfo() |
ConsumerInfo |
DemandSubscription.getRemoteInfo() |
Modifier and Type | Method and Description |
---|---|
protected void |
DemandForwardingBridgeSupport.addConsumerInfo(ConsumerInfo consumerInfo) |
protected void |
DemandForwardingBridgeSupport.addRemoteBrokerToBrokerPath(ConsumerInfo info) |
protected boolean |
ConduitBridge.addToAlreadyInterestedConsumers(ConsumerInfo info,
boolean isForcedDurable) |
protected void |
DemandForwardingBridgeSupport.configureConsumerPrefetch(ConsumerInfo consumerInfo) |
protected void |
DemandForwardingBridgeSupport.configureDemandSubscription(ConsumerInfo info,
DemandSubscription sub) |
NetworkBridgeFilter |
NetworkBridgeFilterFactory.create(ConsumerInfo info,
BrokerId[] remoteBrokerPath,
int messageTTL,
int consumerTTL) |
NetworkBridgeFilter |
ConditionalNetworkBridgeFilterFactory.create(ConsumerInfo info,
BrokerId[] remoteBrokerPath,
int messageTTL,
int consumerTTL) |
NetworkBridgeFilter |
DefaultNetworkBridgeFilterFactory.create(ConsumerInfo info,
BrokerId[] remoteBrokerPath,
int messageTTL,
int consumerTTL) |
protected DemandSubscription |
DurableConduitBridge.createDemandSubscription(ConsumerInfo info) |
protected DemandSubscription |
DemandForwardingBridgeSupport.createDemandSubscription(ConsumerInfo info) |
protected DemandSubscription |
ConduitBridge.createDemandSubscription(ConsumerInfo info) |
protected NetworkBridgeFilter |
DemandForwardingBridgeSupport.createNetworkBridgeFilter(ConsumerInfo info) |
protected DemandSubscription |
DemandForwardingBridgeSupport.doCreateDemandSubscription(ConsumerInfo info) |
Modifier and Type | Method and Description |
---|---|
Subscription |
SubQueueSelectorCacheBroker.addConsumer(ConnectionContext context,
ConsumerInfo info) |
void |
SubQueueSelectorCacheBroker.removeConsumer(ConnectionContext context,
ConsumerInfo info) |
Modifier and Type | Method and Description |
---|---|
Subscription |
AuthorizationBroker.addConsumer(ConnectionContext context,
ConsumerInfo info) |
Modifier and Type | Method and Description |
---|---|
Subscription |
AuthorizationFilter.addConsumer(ConnectionContext context,
ConsumerInfo info) |
Modifier and Type | Method and Description |
---|---|
ConsumerInfo |
ConsumerState.getInfo() |
Modifier and Type | Method and Description |
---|---|
Map<ConsumerId,ConsumerInfo> |
ConnectionState.getRecoveringPullConsumers() |
Modifier and Type | Method and Description |
---|---|
void |
SessionState.addConsumer(ConsumerInfo info) |
Response |
CommandVisitorAdapter.processAddConsumer(ConsumerInfo info) |
Response |
ConnectionStateTracker.processAddConsumer(ConsumerInfo info) |
Response |
CommandVisitor.processAddConsumer(ConsumerInfo info) |
Constructor and Description |
---|
ConsumerState(ConsumerInfo info) |
Modifier and Type | Method and Description |
---|---|
ConsumerInfo |
MQTTSubscription.getConsumerInfo()
Gets the
ConsumerInfo that describes the subscription sent to ActiveMQ. |
Constructor and Description |
---|
MQTTSubscription(MQTTProtocolConverter protocolConverter,
String topicName,
org.fusesource.mqtt.client.QoS qos,
ConsumerInfo consumerInfo) |
Modifier and Type | Method and Description |
---|---|
protected byte |
AbstractMQTTSubscriptionStrategy.doSubscribe(ConsumerInfo consumerInfo,
String topicName,
org.fusesource.mqtt.client.QoS qoS) |
Modifier and Type | Field and Description |
---|---|
protected ConsumerInfo |
StompSubscription.consumerInfo |
Modifier and Type | Method and Description |
---|---|
ConsumerInfo |
StompSubscription.getConsumerInfo() |
Constructor and Description |
---|
StompQueueBrowserSubscription(ProtocolConverter stompTransport,
String subscriptionId,
ConsumerInfo consumerInfo,
String transformation) |
StompSubscription(ProtocolConverter stompTransport,
String subscriptionId,
ConsumerInfo consumerInfo,
String transformation) |
Modifier and Type | Method and Description |
---|---|
static boolean |
NetworkBridgeUtils.isForcedDurable(ConsumerInfo info,
ActiveMQDestination[] dynamicallyIncludedDestinations,
ActiveMQDestination[] staticallyIncludedDestinations) |
static boolean |
NetworkBridgeUtils.isForcedDurable(ConsumerInfo info,
List<ActiveMQDestination> dynamicallyIncludedDestinations) |
Copyright © 2005–2017 The Apache Software Foundation. All rights reserved.