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 ConsumerInfoActiveMQMessageConsumer. infoMethods in org.apache.activemq that return ConsumerInfo Modifier and Type Method Description ConsumerInfoActiveMQConnectionConsumer. 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. brokerConsumerDestsThis 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. consumersprotected ConcurrentMap<ConsumerInfo,VirtualDestination>AdvisoryBroker. virtualDestinationConsumersThis 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 ConsumerInfoConsumerStartedEvent. 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 SubscriptionAdvisoryBroker. addConsumer(ConnectionContext context, ConsumerInfo info)voidAdvisoryBroker. 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 SubscriptionBrokerBroadcaster. addConsumer(ConnectionContext context, ConsumerInfo info)SubscriptionBrokerFilter. addConsumer(ConnectionContext context, ConsumerInfo info)SubscriptionEmptyBroker. addConsumer(ConnectionContext context, ConsumerInfo info)SubscriptionErrorBroker. addConsumer(ConnectionContext context, ConsumerInfo info)ResponseTransportConnection. processAddConsumer(ConsumerInfo info)voidBrokerBroadcaster. removeConsumer(ConnectionContext context, ConsumerInfo info)voidBrokerFilter. removeConsumer(ConnectionContext context, ConsumerInfo info)voidEmptyBroker. removeConsumer(ConnectionContext context, ConsumerInfo info)voidErrorBroker. 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 SubscriptionConnectionSplitBroker. addConsumer(ConnectionContext context, ConsumerInfo info)voidConnectionSplitBroker. 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 ConsumerInfoInactiveDurableSubscriptionView. getConsumerInfo()protected ConsumerInfoSubscriptionView. getConsumerInfo()Methods in org.apache.activemq.broker.jmx with parameters of type ConsumerInfo Modifier and Type Method Description SubscriptionManagedRegionBroker. addConsumer(ConnectionContext context, ConsumerInfo info)protected SubscriptionManagedQueueRegion. createSubscription(ConnectionContext context, ConsumerInfo info)protected SubscriptionManagedTempQueueRegion. createSubscription(ConnectionContext context, ConsumerInfo info)protected SubscriptionManagedTempTopicRegion. createSubscription(ConnectionContext context, ConsumerInfo info)protected SubscriptionManagedTopicRegion. createSubscription(ConnectionContext context, ConsumerInfo info)static ObjectNameBrokerMBeanSupport. createSubscriptionName(String brokerObjectName, String connectionClientId, ConsumerInfo info)static ObjectNameBrokerMBeanSupport. createSubscriptionName(ObjectName brokerObjectName, String connectionClientId, ConsumerInfo info)protected voidManagedRegionBroker. registerSubscription(ObjectName key, ConsumerInfo info, SubscriptionKey subscriptionKey, SubscriptionView view)voidManagedRegionBroker. 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 ConsumerInfoAbstractSubscription. infoMethods in org.apache.activemq.broker.region that return ConsumerInfo Modifier and Type Method Description ConsumerInfoTopicRegion. createInactiveConsumerInfo(SubscriptionInfo info)ConsumerInfoAbstractSubscription. getConsumerInfo()ConsumerInfoSubscription. getConsumerInfo()The ConsumerInfo object that created the subscription.ConsumerInfoAbstractSubscription. 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 SubscriptionDestinationPathSeparatorBroker. addConsumer(ConnectionContext context, ConsumerInfo info)SubscriptionLoggingBrokerPlugin. addConsumer(ConnectionContext context, ConsumerInfo info)SubscriptionUDPTraceBrokerPlugin. addConsumer(ConnectionContext context, ConsumerInfo info)voidDestinationPathSeparatorBroker. removeConsumer(ConnectionContext context, ConsumerInfo info)voidLoggingBrokerPlugin. removeConsumer(ConnectionContext context, ConsumerInfo info)voidUDPTraceBrokerPlugin. 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 SubscriptionConnectionDotFileInterceptor. addConsumer(ConnectionContext context, ConsumerInfo info)voidConnectionDotFileInterceptor. 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 ConsumerInfoConsumerInfo. copy()ConsumerInfo[]BrokerSubscriptionInfo. getSubscriptionInfos()Methods in org.apache.activemq.command with parameters of type ConsumerInfo Modifier and Type Method Description voidMessagePull. configure(ConsumerInfo info)Configures a message pull from the consumer informationvoidConsumerInfo. copy(ConsumerInfo info)voidBrokerSubscriptionInfo. 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 ConsumerInfoDemandForwardingBridgeSupport. demandConsumerInfoMethods in org.apache.activemq.network that return ConsumerInfo Modifier and Type Method Description ConsumerInfoDemandSubscription. getLocalInfo()ConsumerInfoDemandSubscription. getRemoteInfo()Methods in org.apache.activemq.network with parameters of type ConsumerInfo Modifier and Type Method Description protected voidDemandForwardingBridgeSupport. addConsumerInfo(ConsumerInfo consumerInfo)protected voidDemandForwardingBridgeSupport. addRemoteBrokerToBrokerPath(ConsumerInfo info)protected booleanConduitBridge. addToAlreadyInterestedConsumers(ConsumerInfo info, boolean isForcedDurable)protected voidDemandForwardingBridgeSupport. configureConsumerPrefetch(ConsumerInfo consumerInfo)protected voidDemandForwardingBridgeSupport. configureDemandSubscription(ConsumerInfo info, DemandSubscription sub)NetworkBridgeFilterConditionalNetworkBridgeFilterFactory. create(ConsumerInfo info, BrokerId[] remoteBrokerPath, int messageTTL, int consumerTTL)NetworkBridgeFilterDefaultNetworkBridgeFilterFactory. create(ConsumerInfo info, BrokerId[] remoteBrokerPath, int messageTTL, int consumerTTL)NetworkBridgeFilterNetworkBridgeFilterFactory. create(ConsumerInfo info, BrokerId[] remoteBrokerPath, int messageTTL, int consumerTTL)protected DemandSubscriptionConduitBridge. createDemandSubscription(ConsumerInfo info)protected DemandSubscriptionDemandForwardingBridgeSupport. createDemandSubscription(ConsumerInfo info)protected DemandSubscriptionDurableConduitBridge. createDemandSubscription(ConsumerInfo info)protected NetworkBridgeFilterDemandForwardingBridgeSupport. createNetworkBridgeFilter(ConsumerInfo info)protected DemandSubscriptionDemandForwardingBridgeSupport. doCreateDemandSubscription(ConsumerInfo info)protected booleanDemandForwardingBridgeSupport. isDirectBridgeConsumer(ConsumerInfo info)Checks whether or not this consumer is a direct bridge network subscriptionprotected booleanDemandForwardingBridgeSupport. 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 SubscriptionSubQueueSelectorCacheBroker. addConsumer(ConnectionContext context, ConsumerInfo info)voidSubQueueSelectorCacheBroker. 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 SubscriptionAuthorizationBroker. 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 SubscriptionAuthorizationFilter. 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 ConsumerInfoConsumerState. 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 voidSessionState. addConsumer(ConsumerInfo info)ResponseCommandVisitor. processAddConsumer(ConsumerInfo info)ResponseCommandVisitorAdapter. processAddConsumer(ConsumerInfo info)ResponseConnectionStateTracker. 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 ConsumerInfoMQTTSubscription. getConsumerInfo()Gets theConsumerInfothat 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 byteAbstractMQTTSubscriptionStrategy. 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 ConsumerInfoStompSubscription. consumerInfoMethods in org.apache.activemq.transport.stomp that return ConsumerInfo Modifier and Type Method Description ConsumerInfoStompSubscription. 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 booleanNetworkBridgeUtils. isForcedDurable(ConsumerInfo info, List<ActiveMQDestination> dynamicallyIncludedDestinations)static booleanNetworkBridgeUtils. isForcedDurable(ConsumerInfo info, ActiveMQDestination[] dynamicallyIncludedDestinations, ActiveMQDestination[] staticallyIncludedDestinations)
-