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.region |
Region abstraction and implementations in the Broker.
|
org.apache.activemq.broker.region.group |
Classes to implement the Message Groups feature.
|
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.state |
Modifier and Type | Method and Description |
---|---|
ConsumerId |
ActiveMQMessageConsumer.getConsumerId() |
protected ConsumerId |
ActiveMQSession.getNextConsumerId() |
Modifier and Type | Method and Description |
---|---|
void |
ActiveMQConnection.addDispatcher(ConsumerId consumerId,
ActiveMQDispatcher dispatcher) |
protected void |
ActiveMQSession.close(ConsumerId id) |
void |
ActiveMQConnection.removeDispatcher(ConsumerId consumerId) |
protected void |
ActiveMQSession.setPrefetchSize(ConsumerId id,
int prefetch) |
Constructor and Description |
---|
ActiveMQInputStream(ActiveMQConnection connection,
ConsumerId consumerId,
ActiveMQDestination dest,
String selector,
boolean noLocal,
String name,
int prefetch,
long timeout) |
ActiveMQMessageConsumer(ActiveMQSession session,
ConsumerId consumerId,
ActiveMQDestination dest,
String name,
String selector,
int prefetch,
int maximumPendingMessageCount,
boolean noLocal,
boolean browser,
boolean dispatchAsync,
javax.jms.MessageListener messageListener)
Create a MessageConsumer
|
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) |
ActiveMQTopicSubscriber(ActiveMQSession theSession,
ConsumerId consumerId,
ActiveMQDestination dest,
String name,
String selector,
int prefetch,
int maximumPendingMessageCount,
boolean noLocalValue,
boolean browserValue,
boolean asyncDispatch) |
AdvisoryConsumer(ActiveMQConnection connection,
ConsumerId consumerId) |
Modifier and Type | Field and Description |
---|---|
protected ConcurrentHashMap<ConsumerId,ConsumerInfo> |
AdvisoryBroker.consumers |
Modifier and Type | Method and Description |
---|---|
ConsumerId |
ConsumerEvent.getConsumerId() |
Modifier and Type | Method and Description |
---|---|
Map<ConsumerId,ConsumerInfo> |
AdvisoryBroker.getAdvisoryConsumers() |
Modifier and Type | Method and Description |
---|---|
protected void |
AdvisoryBroker.fireAdvisory(ConnectionContext context,
ActiveMQTopic topic,
Command command,
ConsumerId targetConsumerId) |
protected void |
AdvisoryBroker.fireAdvisory(ConnectionContext context,
ActiveMQTopic topic,
Command command,
ConsumerId targetConsumerId,
ActiveMQMessage advisoryMessage) |
protected void |
AdvisoryBroker.fireConsumerAdvisory(ConnectionContext context,
ActiveMQDestination consumerDestination,
ActiveMQTopic topic,
Command command,
ConsumerId targetConsumerId) |
protected void |
AdvisoryBroker.fireProducerAdvisory(ConnectionContext context,
ActiveMQDestination producerDestination,
ActiveMQTopic topic,
Command command,
ConsumerId targetConsumerId) |
Constructor and Description |
---|
ConsumerEvent(ConsumerEventSource source,
javax.jms.Destination destination,
ConsumerId consumerId,
int consumerCount) |
ConsumerStoppedEvent(ConsumerEventSource source,
ActiveMQDestination destination,
ConsumerId consumerId,
int count) |
Modifier and Type | Method and Description |
---|---|
TransportConnectionState |
MapTransportConnectionStateRegister.lookupConnectionState(ConsumerId id) |
TransportConnectionState |
SingleTransportConnectionStateRegister.lookupConnectionState(ConsumerId id) |
TransportConnectionState |
TransportConnectionStateRegister.lookupConnectionState(ConsumerId id) |
protected TransportConnectionState |
TransportConnection.lookupConnectionState(ConsumerId id) |
Response |
TransportConnection.processRemoveConsumer(ConsumerId id,
long lastDeliveredSequenceId) |
Modifier and Type | Field and Description |
---|---|
protected Map<ConsumerId,Object> |
AbstractRegion.consumerChangeMutexMap |
protected Map<ConsumerId,Subscription> |
AbstractRegion.subscriptions |
Modifier and Type | Method and Description |
---|---|
ConsumerId |
MessageReference.getTargetConsumerId() |
ConsumerId |
IndirectMessageReference.getTargetConsumerId() |
Modifier and Type | Method and Description |
---|---|
Map<ConsumerId,Subscription> |
AbstractRegion.getSubscriptions() |
Modifier and Type | Method and Description |
---|---|
ConsumerId |
MessageGroupMap.get(String groupId) |
ConsumerId |
SimpleMessageGroupMap.get(String groupId) |
ConsumerId |
MessageGroupHashBucket.get(String groupId) |
ConsumerId |
MessageGroupMap.removeGroup(String groupId) |
ConsumerId |
SimpleMessageGroupMap.removeGroup(String groupId) |
ConsumerId |
MessageGroupHashBucket.removeGroup(String groupId) |
Modifier and Type | Method and Description |
---|---|
void |
MessageGroupMap.put(String groupId,
ConsumerId consumerId) |
void |
SimpleMessageGroupMap.put(String groupId,
ConsumerId consumerId) |
void |
MessageGroupHashBucket.put(String groupId,
ConsumerId consumerId) |
MessageGroupSet |
MessageGroupMap.removeConsumer(ConsumerId consumerId) |
MessageGroupSet |
SimpleMessageGroupMap.removeConsumer(ConsumerId consumerId) |
MessageGroupSet |
MessageGroupHashBucket.removeConsumer(ConsumerId consumerId) |
Modifier and Type | Field and Description |
---|---|
protected ConsumerId |
MessageDispatch.consumerId |
protected ConsumerId |
MessageAck.consumerId |
protected ConsumerId |
MessageDispatchNotification.consumerId |
protected ConsumerId |
MessagePull.consumerId |
protected ConsumerId |
ConsumerInfo.consumerId |
protected ConsumerId |
ConsumerControl.consumerId |
protected ConsumerId |
Message.targetConsumerId |
Modifier and Type | Field and Description |
---|---|
protected List<ConsumerId> |
ConsumerInfo.networkConsumerIds |
Modifier and Type | Method and Description |
---|---|
ConsumerId |
MessageDispatch.getConsumerId() |
ConsumerId |
MessageAck.getConsumerId() |
ConsumerId |
MessageDispatchNotification.getConsumerId() |
ConsumerId |
MessagePull.getConsumerId() |
ConsumerId |
ConsumerInfo.getConsumerId()
Is used to uniquely identify the consumer to the broker.
|
ConsumerId |
ConsumerControl.getConsumerId() |
ConsumerId[] |
ConsumerInfo.getNetworkConsumerPath()
Tracks the original subscription id that causes a subscription to
percolate through a network when networkTTL > 1.
|
ConsumerId |
Message.getTargetConsumerId()
Can be used to route the message to a specific consumer.
|
Modifier and Type | Method and Description |
---|---|
List<ConsumerId> |
ConsumerInfo.getNetworkConsumerIds() |
Modifier and Type | Method and Description |
---|---|
void |
ConsumerInfo.addNetworkConsumerId(ConsumerId networkConsumerId) |
void |
ConsumerInfo.removeNetworkConsumerId(ConsumerId networkConsumerId) |
void |
MessageDispatch.setConsumerId(ConsumerId consumerId) |
void |
MessageAck.setConsumerId(ConsumerId consumerId) |
void |
MessageDispatchNotification.setConsumerId(ConsumerId consumerId) |
void |
MessagePull.setConsumerId(ConsumerId consumerId) |
void |
ConsumerInfo.setConsumerId(ConsumerId consumerId) |
void |
ConsumerControl.setConsumerId(ConsumerId consumerId) |
void |
ConsumerInfo.setNetworkConsumerPath(ConsumerId[] consumerPath) |
void |
Message.setTargetConsumerId(ConsumerId targetConsumerId) |
Constructor and Description |
---|
ConnectionId(ConsumerId id) |
ConsumerId(ConsumerId id) |
ConsumerInfo(ConsumerId consumerId) |
SessionId(ConsumerId id) |
Modifier and Type | Field and Description |
---|---|
protected ConcurrentHashMap<ConsumerId,DemandSubscription> |
DemandForwardingBridgeSupport.subscriptionMapByLocalId |
protected ConcurrentHashMap<ConsumerId,DemandSubscription> |
DemandForwardingBridgeSupport.subscriptionMapByRemoteId |
Modifier and Type | Method and Description |
---|---|
ConcurrentHashMap<ConsumerId,DemandSubscription> |
DemandForwardingBridgeSupport.getLocalSubscriptionMap() |
Modifier and Type | Method and Description |
---|---|
boolean |
DemandSubscription.add(ConsumerId id)
Increment the consumers associated with this subscription
|
boolean |
DemandSubscription.remove(ConsumerId id)
Increment the consumers associated with this subscription
|
protected void |
DemandForwardingBridgeSupport.removeDemandSubscription(ConsumerId id) |
boolean |
NetworkConnector.removeDemandSubscription(ConsumerId consumerId) |
protected void |
ConduitBridge.removeDemandSubscription(ConsumerId id) |
protected boolean |
DemandForwardingBridgeSupport.removeDemandSubscriptionByLocalId(ConsumerId consumerId) |
Modifier and Type | Method and Description |
---|---|
Set<ConsumerId> |
SessionState.getConsumerIds() |
Map<ConsumerId,ConsumerInfo> |
ConnectionState.getRecoveringPullConsumers() |
Modifier and Type | Method and Description |
---|---|
ConsumerState |
SessionState.getConsumerState(ConsumerId consumerId) |
Response |
ConnectionStateTracker.processRemoveConsumer(ConsumerId id,
long lastDeliveredSequenceId) |
Response |
CommandVisitor.processRemoveConsumer(ConsumerId id,
long lastDeliveredSequenceId) |
Response |
CommandVisitorAdapter.processRemoveConsumer(ConsumerId id,
long lastDeliveredSequenceId) |
ConsumerState |
SessionState.removeConsumer(ConsumerId id) |
Copyright © 2005–2015 The Apache Software Foundation. All rights reserved.