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 ConsumerIdActiveMQMessageConsumer. getConsumerId()protected ConsumerIdActiveMQSession. getNextConsumerId()Methods in org.apache.activemq with parameters of type ConsumerId Modifier and Type Method Description voidActiveMQConnection. addDispatcher(ConsumerId consumerId, ActiveMQDispatcher dispatcher)protected voidActiveMQSession. close(ConsumerId id)booleanActiveMQConnection. hasDispatcher(ConsumerId consumerId)voidActiveMQConnection. removeDispatcher(ConsumerId consumerId)protected voidActiveMQSession. 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. consumersMethods in org.apache.activemq.advisory that return ConsumerId Modifier and Type Method Description ConsumerIdConsumerEvent. getConsumerId()Methods in org.apache.activemq.advisory with parameters of type ConsumerId Modifier and Type Method Description protected voidAdvisoryBroker. fireAdvisory(ConnectionContext context, ActiveMQTopic topic, Command command, ConsumerId targetConsumerId)voidAdvisoryBroker. fireAdvisory(ConnectionContext context, ActiveMQTopic topic, Command command, ConsumerId targetConsumerId, ActiveMQMessage advisoryMessage)protected voidAdvisoryBroker. fireConsumerAdvisory(ConnectionContext context, ActiveMQDestination consumerDestination, ActiveMQTopic topic, Command command, ConsumerId targetConsumerId)protected voidAdvisoryBroker. 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 TransportConnectionStateMapTransportConnectionStateRegister. lookupConnectionState(ConsumerId id)TransportConnectionStateSingleTransportConnectionStateRegister. lookupConnectionState(ConsumerId id)protected TransportConnectionStateTransportConnection. lookupConnectionState(ConsumerId id)TransportConnectionStateTransportConnectionStateRegister. lookupConnectionState(ConsumerId id)ResponseTransportConnection. 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. consumerChangeMutexMapprotected Map<ConsumerId,Subscription>AbstractRegion. subscriptionsMethods in org.apache.activemq.broker.region that return ConsumerId Modifier and Type Method Description ConsumerIdIndirectMessageReference. getTargetConsumerId()ConsumerIdMessageReference. getTargetConsumerId()ConsumerIdNullMessageReference. 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 ConsumerIdCachedMessageGroupMap. get(String groupId)ConsumerIdMessageGroupHashBucket. get(String groupId)ConsumerIdMessageGroupMap. get(String groupId)ConsumerIdSimpleMessageGroupMap. get(String groupId)ConsumerIdCachedMessageGroupMap. removeGroup(String groupId)ConsumerIdMessageGroupHashBucket. removeGroup(String groupId)ConsumerIdMessageGroupMap. removeGroup(String groupId)ConsumerIdSimpleMessageGroupMap. removeGroup(String groupId)Methods in org.apache.activemq.broker.region.group with parameters of type ConsumerId Modifier and Type Method Description voidCachedMessageGroupMap. put(String groupId, ConsumerId consumerId)voidMessageGroupHashBucket. put(String groupId, ConsumerId consumerId)voidMessageGroupMap. put(String groupId, ConsumerId consumerId)voidSimpleMessageGroupMap. put(String groupId, ConsumerId consumerId)MessageGroupSetCachedMessageGroupMap. removeConsumer(ConsumerId consumerId)MessageGroupSetMessageGroupHashBucket. removeConsumer(ConsumerId consumerId)MessageGroupSetMessageGroupMap. removeConsumer(ConsumerId consumerId)MessageGroupSetSimpleMessageGroupMap. 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 ConsumerIdConsumerControl. consumerIdprotected ConsumerIdConsumerInfo. consumerIdprotected ConsumerIdMessageAck. consumerIdprotected ConsumerIdMessageDispatch. consumerIdprotected ConsumerIdMessageDispatchNotification. consumerIdprotected ConsumerIdMessagePull. consumerIdprotected ConsumerIdMessage. targetConsumerIdFields in org.apache.activemq.command with type parameters of type ConsumerId Modifier and Type Field Description protected List<ConsumerId>ConsumerInfo. networkConsumerIdsMethods in org.apache.activemq.command that return ConsumerId Modifier and Type Method Description ConsumerIdConsumerControl. getConsumerId()ConsumerIdConsumerInfo. getConsumerId()Is used to uniquely identify the consumer to the broker.ConsumerIdMessageAck. getConsumerId()ConsumerIdMessageDispatch. getConsumerId()ConsumerIdMessageDispatchNotification. getConsumerId()ConsumerIdMessagePull. getConsumerId()ConsumerId[]ConsumerInfo. getNetworkConsumerPath()Tracks the original subscription id that causes a subscription to percolate through a network when networkTTL > 1.ConsumerIdMessage. 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 voidConsumerInfo. addNetworkConsumerId(ConsumerId networkConsumerId)voidConsumerInfo. removeNetworkConsumerId(ConsumerId networkConsumerId)voidConsumerControl. setConsumerId(ConsumerId consumerId)voidConsumerInfo. setConsumerId(ConsumerId consumerId)voidMessageAck. setConsumerId(ConsumerId consumerId)voidMessageDispatch. setConsumerId(ConsumerId consumerId)voidMessageDispatchNotification. setConsumerId(ConsumerId consumerId)voidMessagePull. setConsumerId(ConsumerId consumerId)voidConsumerInfo. setNetworkConsumerPath(ConsumerId[] consumerPath)voidMessage. 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. forcedDurableRemoteIdprotected ConcurrentMap<ConsumerId,DemandSubscription>DemandForwardingBridgeSupport. subscriptionMapByLocalIdprotected ConcurrentMap<ConsumerId,DemandSubscription>DemandForwardingBridgeSupport. subscriptionMapByRemoteIdMethods 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 booleanDemandSubscription. add(ConsumerId id)Increment the consumers associated with this subscriptionbooleanDemandSubscription. addForcedDurableConsumer(ConsumerId id)booleanDemandSubscription. remove(ConsumerId id)Increment the consumers associated with this subscriptionprotected voidConduitBridge. removeDemandSubscription(ConsumerId id)protected voidDemandForwardingBridgeSupport. removeDemandSubscription(ConsumerId id)booleanNetworkConnector. removeDemandSubscription(ConsumerId consumerId)protected booleanDemandForwardingBridgeSupport. removeDemandSubscriptionByLocalId(ConsumerId consumerId)booleanDemandSubscription. 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 ConsumerStateSessionState. getConsumerState(ConsumerId consumerId)ResponseCommandVisitor. processRemoveConsumer(ConsumerId id, long lastDeliveredSequenceId)ResponseCommandVisitorAdapter. processRemoveConsumer(ConsumerId id, long lastDeliveredSequenceId)ResponseConnectionStateTracker. processRemoveConsumer(ConsumerId id, long lastDeliveredSequenceId)ConsumerStateSessionState. 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 ConsumerIdAmqpSender. getConsumerId()Methods in org.apache.activemq.transport.amqp.protocol with parameters of type ConsumerId Modifier and Type Method Description voidAmqpSession. registerSender(ConsumerId consumerId, AmqpSender sender)voidAmqpSession. 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. subscriptionsByConsumerIdMethods in org.apache.activemq.transport.mqtt.strategy that return ConsumerId Modifier and Type Method Description protected ConsumerIdAbstractMQTTSubscriptionStrategy. getNextConsumerId()Methods in org.apache.activemq.transport.mqtt.strategy with parameters of type ConsumerId Modifier and Type Method Description MQTTSubscriptionAbstractMQTTSubscriptionStrategy. getSubscription(ConsumerId consumerId)MQTTSubscriptionMQTTSubscriptionStrategy. getSubscription(ConsumerId consumer)Lookup anMQTTSubscriptioninstance based on knownConsumerIdvalue.
-