Uses of Class
org.apache.activemq.command.ConsumerId
-
Packages that use ConsumerId 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 nodesorg.apache.activemq.network Support for federated networks of brokers.org.apache.activemq.state org.apache.activemq.transport.amqp.protocol org.apache.activemq.transport.mqtt.strategy -
-
Uses of ConsumerId in org.apache.activemq
Methods in org.apache.activemq that return ConsumerId Modifier and Type Method Description ConsumerId
ActiveMQMessageConsumer. getConsumerId()
protected ConsumerId
ActiveMQSession. getNextConsumerId()
Methods in org.apache.activemq with parameters of type ConsumerId Modifier and Type Method Description void
ActiveMQConnection. addDispatcher(ConsumerId consumerId, ActiveMQDispatcher dispatcher)
protected void
ActiveMQSession. close(ConsumerId id)
boolean
ActiveMQConnection. hasDispatcher(ConsumerId consumerId)
void
ActiveMQConnection. removeDispatcher(ConsumerId consumerId)
protected void
ActiveMQSession. setPrefetchSize(ConsumerId id, int prefetch)
Constructors in org.apache.activemq with parameters of type ConsumerId Constructor Description ActiveMQMessageConsumer(ActiveMQSession session, ConsumerId consumerId, ActiveMQDestination dest, String name, String selector, int prefetch, int maximumPendingMessageCount, boolean noLocal, boolean browser, boolean dispatchAsync, MessageListener messageListener)
Create a MessageConsumerActiveMQQueueBrowser(ActiveMQSession session, ConsumerId consumerId, ActiveMQDestination destination, String selector, boolean dispatchAsync)
Constructor for an ActiveMQQueueBrowser - used internallyActiveMQQueueReceiver(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)
-
Uses of ConsumerId in org.apache.activemq.advisory
Fields in org.apache.activemq.advisory with type parameters of type ConsumerId Modifier and Type Field Description protected Map<ConsumerId,ConsumerInfo>
AdvisoryBroker. consumers
Methods in org.apache.activemq.advisory that return ConsumerId Modifier and Type Method Description ConsumerId
ConsumerEvent. getConsumerId()
Methods in org.apache.activemq.advisory with parameters of type ConsumerId Modifier and Type Method Description protected void
AdvisoryBroker. fireAdvisory(ConnectionContext context, ActiveMQTopic topic, Command command, ConsumerId targetConsumerId)
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)
Constructors in org.apache.activemq.advisory with parameters of type ConsumerId Constructor Description ConsumerEvent(ConsumerEventSource source, Destination destination, ConsumerId consumerId, int consumerCount)
ConsumerStoppedEvent(ConsumerEventSource source, ActiveMQDestination destination, ConsumerId consumerId, int count)
-
Uses of ConsumerId in org.apache.activemq.broker
Methods in org.apache.activemq.broker with parameters of type ConsumerId Modifier and Type Method Description TransportConnectionState
MapTransportConnectionStateRegister. lookupConnectionState(ConsumerId id)
TransportConnectionState
SingleTransportConnectionStateRegister. lookupConnectionState(ConsumerId id)
protected TransportConnectionState
TransportConnection. lookupConnectionState(ConsumerId id)
TransportConnectionState
TransportConnectionStateRegister. lookupConnectionState(ConsumerId id)
Response
TransportConnection. processRemoveConsumer(ConsumerId id, long lastDeliveredSequenceId)
-
Uses of ConsumerId in org.apache.activemq.broker.region
Fields in org.apache.activemq.broker.region with type parameters of type ConsumerId Modifier and Type Field Description protected Map<ConsumerId,Object>
AbstractRegion. consumerChangeMutexMap
protected Map<ConsumerId,Subscription>
AbstractRegion. subscriptions
Methods in org.apache.activemq.broker.region that return ConsumerId Modifier and Type Method Description ConsumerId
IndirectMessageReference. getTargetConsumerId()
ConsumerId
MessageReference. getTargetConsumerId()
ConsumerId
NullMessageReference. getTargetConsumerId()
Methods in org.apache.activemq.broker.region that return types with arguments of type ConsumerId Modifier and Type Method Description Map<ConsumerId,Subscription>
AbstractRegion. getSubscriptions()
-
Uses of ConsumerId in org.apache.activemq.broker.region.group
Methods in org.apache.activemq.broker.region.group that return ConsumerId Modifier and Type Method Description ConsumerId
CachedMessageGroupMap. get(String groupId)
ConsumerId
MessageGroupHashBucket. get(String groupId)
ConsumerId
MessageGroupMap. get(String groupId)
ConsumerId
SimpleMessageGroupMap. get(String groupId)
ConsumerId
CachedMessageGroupMap. removeGroup(String groupId)
ConsumerId
MessageGroupHashBucket. removeGroup(String groupId)
ConsumerId
MessageGroupMap. removeGroup(String groupId)
ConsumerId
SimpleMessageGroupMap. removeGroup(String groupId)
Methods in org.apache.activemq.broker.region.group with parameters of type ConsumerId Modifier and Type Method Description void
CachedMessageGroupMap. put(String groupId, ConsumerId consumerId)
void
MessageGroupHashBucket. put(String groupId, ConsumerId consumerId)
void
MessageGroupMap. put(String groupId, ConsumerId consumerId)
void
SimpleMessageGroupMap. put(String groupId, ConsumerId consumerId)
MessageGroupSet
CachedMessageGroupMap. removeConsumer(ConsumerId consumerId)
MessageGroupSet
MessageGroupHashBucket. removeConsumer(ConsumerId consumerId)
MessageGroupSet
MessageGroupMap. removeConsumer(ConsumerId consumerId)
MessageGroupSet
SimpleMessageGroupMap. removeConsumer(ConsumerId consumerId)
-
Uses of ConsumerId in org.apache.activemq.command
Fields in org.apache.activemq.command declared as ConsumerId Modifier and Type Field Description protected ConsumerId
ConsumerControl. consumerId
protected ConsumerId
ConsumerInfo. consumerId
protected ConsumerId
MessageAck. consumerId
protected ConsumerId
MessageDispatch. consumerId
protected ConsumerId
MessageDispatchNotification. consumerId
protected ConsumerId
MessagePull. consumerId
protected ConsumerId
Message. targetConsumerId
Fields in org.apache.activemq.command with type parameters of type ConsumerId Modifier and Type Field Description protected List<ConsumerId>
ConsumerInfo. networkConsumerIds
Methods in org.apache.activemq.command that return ConsumerId Modifier and Type Method Description ConsumerId
ConsumerControl. getConsumerId()
ConsumerId
ConsumerInfo. getConsumerId()
Is used to uniquely identify the consumer to the broker.ConsumerId
MessageAck. getConsumerId()
ConsumerId
MessageDispatch. getConsumerId()
ConsumerId
MessageDispatchNotification. getConsumerId()
ConsumerId
MessagePull. 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.Methods in org.apache.activemq.command that return types with arguments of type ConsumerId Modifier and Type Method Description List<ConsumerId>
ConsumerInfo. getNetworkConsumerIds()
Methods in org.apache.activemq.command with parameters of type ConsumerId Modifier and Type Method Description void
ConsumerInfo. addNetworkConsumerId(ConsumerId networkConsumerId)
void
ConsumerInfo. removeNetworkConsumerId(ConsumerId networkConsumerId)
void
ConsumerControl. setConsumerId(ConsumerId consumerId)
void
ConsumerInfo. setConsumerId(ConsumerId consumerId)
void
MessageAck. setConsumerId(ConsumerId consumerId)
void
MessageDispatch. setConsumerId(ConsumerId consumerId)
void
MessageDispatchNotification. setConsumerId(ConsumerId consumerId)
void
MessagePull. setConsumerId(ConsumerId consumerId)
void
ConsumerInfo. setNetworkConsumerPath(ConsumerId[] consumerPath)
void
Message. setTargetConsumerId(ConsumerId targetConsumerId)
Constructors in org.apache.activemq.command with parameters of type ConsumerId Constructor Description ConnectionId(ConsumerId id)
ConsumerId(ConsumerId id)
ConsumerInfo(ConsumerId consumerId)
SessionId(ConsumerId id)
-
Uses of ConsumerId in org.apache.activemq.network
Fields in org.apache.activemq.network with type parameters of type ConsumerId Modifier and Type Field Description protected Set<ConsumerId>
DemandForwardingBridgeSupport. forcedDurableRemoteId
protected ConcurrentMap<ConsumerId,DemandSubscription>
DemandForwardingBridgeSupport. subscriptionMapByLocalId
protected ConcurrentMap<ConsumerId,DemandSubscription>
DemandForwardingBridgeSupport. subscriptionMapByRemoteId
Methods in org.apache.activemq.network that return types with arguments of type ConsumerId Modifier and Type Method Description ConcurrentMap<ConsumerId,DemandSubscription>
DemandForwardingBridgeSupport. getLocalSubscriptionMap()
Methods in org.apache.activemq.network with parameters of type ConsumerId Modifier and Type Method Description boolean
DemandSubscription. add(ConsumerId id)
Increment the consumers associated with this subscriptionboolean
DemandSubscription. addForcedDurableConsumer(ConsumerId id)
boolean
DemandSubscription. remove(ConsumerId id)
Increment the consumers associated with this subscriptionprotected void
ConduitBridge. removeDemandSubscription(ConsumerId id)
protected void
DemandForwardingBridgeSupport. removeDemandSubscription(ConsumerId id)
boolean
NetworkConnector. removeDemandSubscription(ConsumerId consumerId)
protected boolean
DemandForwardingBridgeSupport. removeDemandSubscriptionByLocalId(ConsumerId consumerId)
boolean
DemandSubscription. removeForcedDurableConsumer(ConsumerId id)
-
Uses of ConsumerId in org.apache.activemq.state
Methods in org.apache.activemq.state that return types with arguments of type ConsumerId Modifier and Type Method Description Set<ConsumerId>
SessionState. getConsumerIds()
Map<ConsumerId,ConsumerInfo>
ConnectionState. getRecoveringPullConsumers()
Methods in org.apache.activemq.state with parameters of type ConsumerId Modifier and Type Method Description ConsumerState
SessionState. getConsumerState(ConsumerId consumerId)
Response
CommandVisitor. processRemoveConsumer(ConsumerId id, long lastDeliveredSequenceId)
Response
CommandVisitorAdapter. processRemoveConsumer(ConsumerId id, long lastDeliveredSequenceId)
Response
ConnectionStateTracker. processRemoveConsumer(ConsumerId id, long lastDeliveredSequenceId)
ConsumerState
SessionState. removeConsumer(ConsumerId id)
-
Uses of ConsumerId in org.apache.activemq.transport.amqp.protocol
Methods in org.apache.activemq.transport.amqp.protocol that return ConsumerId Modifier and Type Method Description ConsumerId
AmqpSender. getConsumerId()
Methods in org.apache.activemq.transport.amqp.protocol with parameters of type ConsumerId Modifier and Type Method Description void
AmqpSession. registerSender(ConsumerId consumerId, AmqpSender sender)
void
AmqpSession. unregisterSender(ConsumerId consumerId)
-
Uses of ConsumerId in org.apache.activemq.transport.mqtt.strategy
Fields in org.apache.activemq.transport.mqtt.strategy with type parameters of type ConsumerId Modifier and Type Field Description protected ConcurrentMap<ConsumerId,MQTTSubscription>
AbstractMQTTSubscriptionStrategy. subscriptionsByConsumerId
Methods in org.apache.activemq.transport.mqtt.strategy that return ConsumerId Modifier and Type Method Description protected ConsumerId
AbstractMQTTSubscriptionStrategy. getNextConsumerId()
Methods in org.apache.activemq.transport.mqtt.strategy with parameters of type ConsumerId Modifier and Type Method Description MQTTSubscription
AbstractMQTTSubscriptionStrategy. getSubscription(ConsumerId consumerId)
MQTTSubscription
MQTTSubscriptionStrategy. getSubscription(ConsumerId consumer)
Lookup anMQTTSubscription
instance based on knownConsumerId
value.
-