Uses of Class
org.apache.activemq.command.ConsumerInfo
-
Packages that use ConsumerInfo 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 Pluginsorg.apache.activemq.broker.view Broker Plugins for visualising the current systemorg.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.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.amqp.protocol 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 -
-
Uses of ConsumerInfo in org.apache.activemq
Fields in org.apache.activemq declared as ConsumerInfo Modifier and Type Field Description protected ConsumerInfo
ActiveMQMessageConsumer. info
Methods in org.apache.activemq that return ConsumerInfo Modifier and Type Method Description ConsumerInfo
ActiveMQConnectionConsumer. getConsumerInfo()
Constructors in org.apache.activemq with parameters of type ConsumerInfo Constructor Description ActiveMQConnectionConsumer(ActiveMQConnection theConnection, ServerSessionPool theSessionPool, ConsumerInfo theConsumerInfo)
Create a ConnectionConsumer -
Uses of ConsumerInfo in org.apache.activemq.advisory
Fields in org.apache.activemq.advisory with type parameters of type ConsumerInfo Modifier and Type Field 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.Methods in org.apache.activemq.advisory that return ConsumerInfo Modifier and Type Method Description ConsumerInfo
ConsumerStartedEvent. getConsumerInfo()
Methods in org.apache.activemq.advisory that return types with arguments of type ConsumerInfo Modifier and Type Method Description Collection<ConsumerInfo>
AdvisoryBroker. getAdvisoryConsumers()
ConcurrentMap<ConsumerInfo,VirtualDestination>
AdvisoryBroker. getVirtualDestinationConsumers()
Methods in org.apache.activemq.advisory with parameters of type ConsumerInfo Modifier and Type Method Description Subscription
AdvisoryBroker. addConsumer(ConnectionContext context, ConsumerInfo info)
void
AdvisoryBroker. removeConsumer(ConnectionContext context, ConsumerInfo info)
Constructors in org.apache.activemq.advisory with parameters of type ConsumerInfo Constructor Description ConsumerStartedEvent(ConsumerEventSource source, ActiveMQDestination destination, ConsumerInfo consumerInfo, int count)
-
Uses of ConsumerInfo in org.apache.activemq.broker
Methods in org.apache.activemq.broker with parameters of type ConsumerInfo Modifier and Type Method Description Subscription
BrokerBroadcaster. addConsumer(ConnectionContext context, ConsumerInfo info)
Subscription
BrokerFilter. addConsumer(ConnectionContext context, ConsumerInfo info)
Subscription
EmptyBroker. addConsumer(ConnectionContext context, ConsumerInfo info)
Subscription
ErrorBroker. addConsumer(ConnectionContext context, ConsumerInfo info)
Response
TransportConnection. processAddConsumer(ConsumerInfo info)
void
BrokerBroadcaster. removeConsumer(ConnectionContext context, ConsumerInfo info)
void
BrokerFilter. removeConsumer(ConnectionContext context, ConsumerInfo info)
void
EmptyBroker. removeConsumer(ConnectionContext context, ConsumerInfo info)
void
ErrorBroker. removeConsumer(ConnectionContext context, ConsumerInfo info)
-
Uses of ConsumerInfo in org.apache.activemq.broker.cluster
Methods in org.apache.activemq.broker.cluster with parameters of type ConsumerInfo Modifier and Type Method Description Subscription
ConnectionSplitBroker. addConsumer(ConnectionContext context, ConsumerInfo info)
void
ConnectionSplitBroker. removeConsumer(ConnectionContext context, ConsumerInfo info)
-
Uses of ConsumerInfo in org.apache.activemq.broker.jmx
Methods in org.apache.activemq.broker.jmx that return ConsumerInfo Modifier and Type Method Description protected ConsumerInfo
InactiveDurableSubscriptionView. getConsumerInfo()
protected ConsumerInfo
SubscriptionView. getConsumerInfo()
Methods in org.apache.activemq.broker.jmx with parameters of type ConsumerInfo Modifier and Type Method Description Subscription
ManagedRegionBroker. addConsumer(ConnectionContext context, ConsumerInfo info)
protected Subscription
ManagedQueueRegion. createSubscription(ConnectionContext context, ConsumerInfo info)
protected Subscription
ManagedTempQueueRegion. createSubscription(ConnectionContext context, ConsumerInfo info)
protected Subscription
ManagedTempTopicRegion. createSubscription(ConnectionContext context, ConsumerInfo info)
protected Subscription
ManagedTopicRegion. createSubscription(ConnectionContext context, ConsumerInfo info)
static ObjectName
BrokerMBeanSupport. createSubscriptionName(String brokerObjectName, String connectionClientId, ConsumerInfo info)
static ObjectName
BrokerMBeanSupport. createSubscriptionName(ObjectName brokerObjectName, String connectionClientId, ConsumerInfo info)
protected void
ManagedRegionBroker. registerSubscription(ObjectName key, ConsumerInfo info, SubscriptionKey subscriptionKey, SubscriptionView view)
void
ManagedRegionBroker. removeConsumer(ConnectionContext context, ConsumerInfo info)
-
Uses of ConsumerInfo in org.apache.activemq.broker.region
Fields in org.apache.activemq.broker.region declared as ConsumerInfo Modifier and Type Field Description protected ConsumerInfo
AbstractSubscription. info
Methods in org.apache.activemq.broker.region that return ConsumerInfo Modifier and Type Method Description ConsumerInfo
TopicRegion. createInactiveConsumerInfo(SubscriptionInfo info)
ConsumerInfo
AbstractSubscription. getConsumerInfo()
ConsumerInfo
Subscription. getConsumerInfo()
The ConsumerInfo object that created the subscription.ConsumerInfo
AbstractSubscription. getInfo()
Constructors in org.apache.activemq.broker.region with parameters of type ConsumerInfo Constructor 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)
-
Uses of ConsumerInfo in org.apache.activemq.broker.util
Methods in org.apache.activemq.broker.util with parameters of type ConsumerInfo Modifier and Type Method Description Subscription
DestinationPathSeparatorBroker. addConsumer(ConnectionContext context, ConsumerInfo info)
Subscription
LoggingBrokerPlugin. addConsumer(ConnectionContext context, ConsumerInfo info)
Subscription
UDPTraceBrokerPlugin. addConsumer(ConnectionContext context, ConsumerInfo info)
void
DestinationPathSeparatorBroker. removeConsumer(ConnectionContext context, ConsumerInfo info)
void
LoggingBrokerPlugin. removeConsumer(ConnectionContext context, ConsumerInfo info)
void
UDPTraceBrokerPlugin. removeConsumer(ConnectionContext context, ConsumerInfo info)
-
Uses of ConsumerInfo in org.apache.activemq.broker.view
Methods in org.apache.activemq.broker.view with parameters of type ConsumerInfo Modifier and Type Method Description Subscription
ConnectionDotFileInterceptor. addConsumer(ConnectionContext context, ConsumerInfo info)
void
ConnectionDotFileInterceptor. removeConsumer(ConnectionContext context, ConsumerInfo info)
-
Uses of ConsumerInfo in org.apache.activemq.command
Methods in org.apache.activemq.command that return ConsumerInfo Modifier and Type Method Description ConsumerInfo
ConsumerInfo. copy()
ConsumerInfo[]
BrokerSubscriptionInfo. getSubscriptionInfos()
Methods in org.apache.activemq.command with parameters of type ConsumerInfo Modifier and Type Method Description void
MessagePull. configure(ConsumerInfo info)
Configures a message pull from the consumer informationvoid
ConsumerInfo. copy(ConsumerInfo info)
void
BrokerSubscriptionInfo. setSubscriptionInfos(ConsumerInfo[] subscriptionInfos)
Constructors in org.apache.activemq.command with parameters of type ConsumerInfo Constructor Description NetworkBridgeFilter(ConsumerInfo consumerInfo, BrokerId networkBrokerId, int messageTTL, int consumerTTL)
-
Uses of ConsumerInfo in org.apache.activemq.network
Fields in org.apache.activemq.network declared as ConsumerInfo Modifier and Type Field Description protected ConsumerInfo
DemandForwardingBridgeSupport. demandConsumerInfo
Methods in org.apache.activemq.network that return ConsumerInfo Modifier and Type Method Description ConsumerInfo
DemandSubscription. getLocalInfo()
ConsumerInfo
DemandSubscription. getRemoteInfo()
Methods in org.apache.activemq.network with parameters of type ConsumerInfo Modifier and Type Method 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
ConditionalNetworkBridgeFilterFactory. create(ConsumerInfo info, BrokerId[] remoteBrokerPath, int messageTTL, int consumerTTL)
NetworkBridgeFilter
DefaultNetworkBridgeFilterFactory. create(ConsumerInfo info, BrokerId[] remoteBrokerPath, int messageTTL, int consumerTTL)
NetworkBridgeFilter
NetworkBridgeFilterFactory. create(ConsumerInfo info, BrokerId[] remoteBrokerPath, int messageTTL, int consumerTTL)
protected DemandSubscription
ConduitBridge. createDemandSubscription(ConsumerInfo info)
protected DemandSubscription
DemandForwardingBridgeSupport. createDemandSubscription(ConsumerInfo info)
protected DemandSubscription
DurableConduitBridge. createDemandSubscription(ConsumerInfo info)
protected NetworkBridgeFilter
DemandForwardingBridgeSupport. createNetworkBridgeFilter(ConsumerInfo info)
protected DemandSubscription
DemandForwardingBridgeSupport. doCreateDemandSubscription(ConsumerInfo info)
protected boolean
DemandForwardingBridgeSupport. isDirectBridgeConsumer(ConsumerInfo info)
Checks whether or not this consumer is a direct bridge network subscriptionprotected boolean
DemandForwardingBridgeSupport. isProxyNSConsumerBrokerPath(ConsumerInfo info)
-
Uses of ConsumerInfo in org.apache.activemq.plugin
Methods in org.apache.activemq.plugin with parameters of type ConsumerInfo Modifier and Type Method Description Subscription
SubQueueSelectorCacheBroker. addConsumer(ConnectionContext context, ConsumerInfo info)
void
SubQueueSelectorCacheBroker. removeConsumer(ConnectionContext context, ConsumerInfo info)
-
Uses of ConsumerInfo in org.apache.activemq.security
Methods in org.apache.activemq.security with parameters of type ConsumerInfo Modifier and Type Method Description Subscription
AuthorizationBroker. addConsumer(ConnectionContext context, ConsumerInfo info)
-
Uses of ConsumerInfo in org.apache.activemq.shiro.authz
Methods in org.apache.activemq.shiro.authz with parameters of type ConsumerInfo Modifier and Type Method Description Subscription
AuthorizationFilter. addConsumer(ConnectionContext context, ConsumerInfo info)
-
Uses of ConsumerInfo in org.apache.activemq.state
Methods in org.apache.activemq.state that return ConsumerInfo Modifier and Type Method Description ConsumerInfo
ConsumerState. getInfo()
Methods in org.apache.activemq.state that return types with arguments of type ConsumerInfo Modifier and Type Method Description Map<ConsumerId,ConsumerInfo>
ConnectionState. getRecoveringPullConsumers()
Methods in org.apache.activemq.state with parameters of type ConsumerInfo Modifier and Type Method Description void
SessionState. addConsumer(ConsumerInfo info)
Response
CommandVisitor. processAddConsumer(ConsumerInfo info)
Response
CommandVisitorAdapter. processAddConsumer(ConsumerInfo info)
Response
ConnectionStateTracker. processAddConsumer(ConsumerInfo info)
Constructors in org.apache.activemq.state with parameters of type ConsumerInfo Constructor Description ConsumerState(ConsumerInfo info)
-
Uses of ConsumerInfo in org.apache.activemq.transport.amqp.protocol
Constructors in org.apache.activemq.transport.amqp.protocol with parameters of type ConsumerInfo Constructor Description AmqpSender(AmqpSession session, org.apache.qpid.proton.engine.Sender endpoint, ConsumerInfo consumerInfo)
Creates a new AmqpSender instance that manages the given Sender -
Uses of ConsumerInfo in org.apache.activemq.transport.mqtt
Methods in org.apache.activemq.transport.mqtt that return ConsumerInfo Modifier and Type Method Description ConsumerInfo
MQTTSubscription. getConsumerInfo()
Gets theConsumerInfo
that describes the subscription sent to ActiveMQ.Constructors in org.apache.activemq.transport.mqtt with parameters of type ConsumerInfo Constructor Description MQTTSubscription(MQTTProtocolConverter protocolConverter, String topicName, org.fusesource.mqtt.client.QoS qos, ConsumerInfo consumerInfo)
-
Uses of ConsumerInfo in org.apache.activemq.transport.mqtt.strategy
Methods in org.apache.activemq.transport.mqtt.strategy with parameters of type ConsumerInfo Modifier and Type Method Description protected byte
AbstractMQTTSubscriptionStrategy. doSubscribe(ConsumerInfo consumerInfo, String topicName, org.fusesource.mqtt.client.QoS qoS)
-
Uses of ConsumerInfo in org.apache.activemq.transport.stomp
Fields in org.apache.activemq.transport.stomp declared as ConsumerInfo Modifier and Type Field Description protected ConsumerInfo
StompSubscription. consumerInfo
Methods in org.apache.activemq.transport.stomp that return ConsumerInfo Modifier and Type Method Description ConsumerInfo
StompSubscription. getConsumerInfo()
Constructors in org.apache.activemq.transport.stomp with parameters of type ConsumerInfo Constructor Description StompQueueBrowserSubscription(ProtocolConverter stompTransport, String subscriptionId, ConsumerInfo consumerInfo, String transformation, Map<String,StompAckEntry> pendingAcks)
StompSubscription(ProtocolConverter stompTransport, String subscriptionId, ConsumerInfo consumerInfo, String transformation, Map<String,StompAckEntry> pendingAcks)
-
Uses of ConsumerInfo in org.apache.activemq.util
Methods in org.apache.activemq.util with parameters of type ConsumerInfo Modifier and Type Method Description static boolean
NetworkBridgeUtils. isForcedDurable(ConsumerInfo info, List<ActiveMQDestination> dynamicallyIncludedDestinations)
static boolean
NetworkBridgeUtils. isForcedDurable(ConsumerInfo info, ActiveMQDestination[] dynamicallyIncludedDestinations, ActiveMQDestination[] staticallyIncludedDestinations)
-