Uses of Class
org.apache.activemq.broker.ConnectionContext
-
Packages that use ConnectionContext Package Description 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.region.cursors Cursors used to page persistent messages into the broker from the storeorg.apache.activemq.broker.region.policy The policies which can be associated with a particular destination or wildcard.org.apache.activemq.broker.region.virtual Implementation classes for Virtual Destinationsorg.apache.activemq.broker.scheduler The Message Scheduler for delayed (or scheduled) message deliveryorg.apache.activemq.broker.util Some utility Broker Pluginsorg.apache.activemq.broker.view Broker Plugins for visualising the current systemorg.apache.activemq.partition 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 org.apache.activemq.shiro.authc org.apache.activemq.shiro.authz org.apache.activemq.shiro.subject org.apache.activemq.store The APIs which need to be implemented for persistent message stores for durable messagingorg.apache.activemq.store.jdbc Message persistence implemented using JDBCorg.apache.activemq.store.journal Message persistence using a high performance transaction log via the Journal interface.org.apache.activemq.store.kahadb org.apache.activemq.store.memory VM based implementation of message persistenceorg.apache.activemq.transaction org.apache.activemq.util -
-
Uses of ConnectionContext in org.apache.activemq.advisory
Methods in org.apache.activemq.advisory with parameters of type ConnectionContext Modifier and Type Method Description void
AdvisoryBroker. addConnection(ConnectionContext context, ConnectionInfo info)
Subscription
AdvisoryBroker. addConsumer(ConnectionContext context, ConsumerInfo info)
Destination
AdvisoryBroker. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean create)
void
AdvisoryBroker. addDestinationInfo(ConnectionContext context, DestinationInfo info)
void
AdvisoryBroker. addProducer(ConnectionContext context, ProducerInfo info)
void
AdvisoryBroker. fastProducer(ConnectionContext context, ProducerInfo producerInfo, ActiveMQDestination destination)
protected void
AdvisoryBroker. fireAdvisory(ConnectionContext context, ActiveMQTopic topic, Command command)
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)
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)
protected void
AdvisoryBroker. fireProducerAdvisory(ConnectionContext context, ActiveMQDestination producerDestination, ActiveMQTopic topic, Command command, ConsumerId targetConsumerId)
void
AdvisoryBroker. isFull(ConnectionContext context, Destination destination, Usage<?> usage)
void
AdvisoryBroker. messageConsumed(ConnectionContext context, MessageReference messageReference)
void
AdvisoryBroker. messageDelivered(ConnectionContext context, MessageReference messageReference)
void
AdvisoryBroker. messageDiscarded(ConnectionContext context, Subscription sub, MessageReference messageReference)
void
AdvisoryBroker. messageExpired(ConnectionContext context, MessageReference messageReference, Subscription subscription)
void
AdvisoryBroker. removeConnection(ConnectionContext context, ConnectionInfo info, Throwable error)
void
AdvisoryBroker. removeConsumer(ConnectionContext context, ConsumerInfo info)
void
AdvisoryBroker. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
void
AdvisoryBroker. removeDestinationInfo(ConnectionContext context, DestinationInfo destInfo)
void
AdvisoryBroker. removeProducer(ConnectionContext context, ProducerInfo info)
void
AdvisoryBroker. removeSubscription(ConnectionContext context, RemoveSubscriptionInfo info)
boolean
AdvisoryBroker. sendToDeadLetterQueue(ConnectionContext context, MessageReference messageReference, Subscription subscription, Throwable poisonCause)
void
AdvisoryBroker. slowConsumer(ConnectionContext context, Destination destination, Subscription subs)
void
AdvisoryBroker. virtualDestinationAdded(ConnectionContext context, VirtualDestination virtualDestination)
void
AdvisoryBroker. virtualDestinationRemoved(ConnectionContext context, VirtualDestination virtualDestination)
-
Uses of ConnectionContext in org.apache.activemq.broker
Methods in org.apache.activemq.broker that return ConnectionContext Modifier and Type Method Description ConnectionContext
ConnectionContext. copy()
ConnectionContext
Broker. getAdminConnectionContext()
ConnectionContext
BrokerFilter. getAdminConnectionContext()
ConnectionContext
BrokerService. getAdminConnectionContext()
Returns the broker's administration connection context used for configuring the broker at startupConnectionContext
EmptyBroker. getAdminConnectionContext()
ConnectionContext
ErrorBroker. getAdminConnectionContext()
ConnectionContext
ConsumerBrokerExchange. getConnectionContext()
ConnectionContext
ProducerBrokerExchange. getConnectionContext()
ConnectionContext
TransportConnectionState. getContext()
Methods in org.apache.activemq.broker with parameters of type ConnectionContext Modifier and Type Method Description void
Broker. addConnection(ConnectionContext context, ConnectionInfo info)
A client is establishing a connection with the broker.void
BrokerBroadcaster. addConnection(ConnectionContext context, ConnectionInfo info)
void
BrokerFilter. addConnection(ConnectionContext context, ConnectionInfo info)
void
EmptyBroker. addConnection(ConnectionContext context, ConnectionInfo info)
void
ErrorBroker. addConnection(ConnectionContext context, ConnectionInfo info)
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)
Destination
BrokerBroadcaster. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean createIfTemporary)
Destination
BrokerFilter. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean createIfTemporary)
Destination
EmptyBroker. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean flag)
Destination
ErrorBroker. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean flag)
void
Broker. addDestinationInfo(ConnectionContext context, DestinationInfo info)
Add and process a DestinationInfo objectvoid
BrokerFilter. addDestinationInfo(ConnectionContext context, DestinationInfo info)
void
EmptyBroker. addDestinationInfo(ConnectionContext context, DestinationInfo info)
void
ErrorBroker. addDestinationInfo(ConnectionContext context, DestinationInfo info)
void
Broker. addProducer(ConnectionContext context, ProducerInfo info)
Adds a producer.void
BrokerBroadcaster. addProducer(ConnectionContext context, ProducerInfo info)
void
BrokerFilter. addProducer(ConnectionContext context, ProducerInfo info)
void
CompositeDestinationBroker. addProducer(ConnectionContext context, ProducerInfo info)
A producer may register to send to multiple destinations via a composite destination.void
EmptyBroker. addProducer(ConnectionContext context, ProducerInfo info)
void
ErrorBroker. addProducer(ConnectionContext context, ProducerInfo info)
void
Broker. addSession(ConnectionContext context, SessionInfo info)
Adds a session.void
BrokerBroadcaster. addSession(ConnectionContext context, SessionInfo info)
void
BrokerFilter. addSession(ConnectionContext context, SessionInfo info)
void
EmptyBroker. addSession(ConnectionContext context, SessionInfo info)
void
ErrorBroker. addSession(ConnectionContext context, SessionInfo info)
void
Broker. beginTransaction(ConnectionContext context, TransactionId xid)
Starts a transaction.void
BrokerBroadcaster. beginTransaction(ConnectionContext context, TransactionId xid)
void
BrokerFilter. beginTransaction(ConnectionContext context, TransactionId xid)
void
EmptyBroker. beginTransaction(ConnectionContext context, TransactionId xid)
void
ErrorBroker. beginTransaction(ConnectionContext context, TransactionId xid)
void
TransactionBroker. beginTransaction(ConnectionContext context, TransactionId xid)
void
Broker. commitTransaction(ConnectionContext context, TransactionId xid, boolean onePhase)
Commits a transaction.void
BrokerBroadcaster. commitTransaction(ConnectionContext context, TransactionId xid, boolean onePhase)
void
BrokerFilter. commitTransaction(ConnectionContext context, TransactionId xid, boolean onePhase)
void
EmptyBroker. commitTransaction(ConnectionContext context, TransactionId xid, boolean onePhase)
void
ErrorBroker. commitTransaction(ConnectionContext context, TransactionId xid, boolean onePhase)
void
TransactionBroker. commitTransaction(ConnectionContext context, TransactionId xid, boolean onePhase)
void
Broker. fastProducer(ConnectionContext context, ProducerInfo producerInfo, ActiveMQDestination destination)
Called to notify a producer is too fastvoid
BrokerFilter. fastProducer(ConnectionContext context, ProducerInfo producerInfo, ActiveMQDestination destination)
void
EmptyBroker. fastProducer(ConnectionContext context, ProducerInfo producerInfo, ActiveMQDestination destination)
void
ErrorBroker. fastProducer(ConnectionContext context, ProducerInfo producerInfo, ActiveMQDestination destination)
void
Broker. forgetTransaction(ConnectionContext context, TransactionId transactionId)
Forgets a transaction.void
BrokerBroadcaster. forgetTransaction(ConnectionContext context, TransactionId transactionId)
void
BrokerFilter. forgetTransaction(ConnectionContext context, TransactionId transactionId)
void
EmptyBroker. forgetTransaction(ConnectionContext context, TransactionId transactionId)
void
ErrorBroker. forgetTransaction(ConnectionContext context, TransactionId transactionId)
void
TransactionBroker. forgetTransaction(ConnectionContext context, TransactionId xid)
TransactionId[]
Broker. getPreparedTransactions(ConnectionContext context)
Gets a list of all the prepared xa transactions.TransactionId[]
BrokerFilter. getPreparedTransactions(ConnectionContext context)
TransactionId[]
EmptyBroker. getPreparedTransactions(ConnectionContext context)
TransactionId[]
ErrorBroker. getPreparedTransactions(ConnectionContext context)
TransactionId[]
TransactionBroker. getPreparedTransactions(ConnectionContext context)
Transaction
TransactionBroker. getTransaction(ConnectionContext context, TransactionId xid, boolean mightBePrepared)
void
Broker. isFull(ConnectionContext context, Destination destination, Usage<?> usage)
Called when a Usage reaches a limitvoid
BrokerFilter. isFull(ConnectionContext context, Destination destination, Usage<?> usage)
void
EmptyBroker. isFull(ConnectionContext context, Destination destination, Usage<?> usage)
void
ErrorBroker. isFull(ConnectionContext context, Destination destination, Usage<?> usage)
void
Broker. messageConsumed(ConnectionContext context, MessageReference messageReference)
called when message is consumedvoid
BrokerFilter. messageConsumed(ConnectionContext context, MessageReference messageReference)
void
EmptyBroker. messageConsumed(ConnectionContext context, MessageReference messageReference)
void
ErrorBroker. messageConsumed(ConnectionContext context, MessageReference messageReference)
void
Broker. messageDelivered(ConnectionContext context, MessageReference messageReference)
Called when message is delivered to the brokervoid
BrokerFilter. messageDelivered(ConnectionContext context, MessageReference messageReference)
void
EmptyBroker. messageDelivered(ConnectionContext context, MessageReference messageReference)
void
ErrorBroker. messageDelivered(ConnectionContext context, MessageReference messageReference)
void
Broker. messageDiscarded(ConnectionContext context, Subscription sub, MessageReference messageReference)
Called when a message is discarded - e.g.void
BrokerFilter. messageDiscarded(ConnectionContext context, Subscription sub, MessageReference messageReference)
void
EmptyBroker. messageDiscarded(ConnectionContext context, Subscription sub, MessageReference messageReference)
void
ErrorBroker. messageDiscarded(ConnectionContext context, Subscription sub, MessageReference messageReference)
void
Broker. messageExpired(ConnectionContext context, MessageReference messageReference, Subscription subscription)
A Message has Expiredvoid
BrokerFilter. messageExpired(ConnectionContext context, MessageReference message, Subscription subscription)
void
EmptyBroker. messageExpired(ConnectionContext context, MessageReference message, Subscription subscription)
void
ErrorBroker. messageExpired(ConnectionContext context, MessageReference message, Subscription subscription)
Response
BrokerFilter. messagePull(ConnectionContext context, MessagePull pull)
Response
EmptyBroker. messagePull(ConnectionContext context, MessagePull pull)
Response
ErrorBroker. messagePull(ConnectionContext context, MessagePull pull)
int
Broker. prepareTransaction(ConnectionContext context, TransactionId xid)
Prepares a transaction.int
BrokerBroadcaster. prepareTransaction(ConnectionContext context, TransactionId xid)
int
BrokerFilter. prepareTransaction(ConnectionContext context, TransactionId xid)
int
EmptyBroker. prepareTransaction(ConnectionContext context, TransactionId xid)
int
ErrorBroker. prepareTransaction(ConnectionContext context, TransactionId xid)
int
TransactionBroker. prepareTransaction(ConnectionContext context, TransactionId xid)
void
Broker. removeConnection(ConnectionContext context, ConnectionInfo info, Throwable error)
A client is disconnecting from the broker.void
BrokerBroadcaster. removeConnection(ConnectionContext context, ConnectionInfo info, Throwable error)
void
BrokerFilter. removeConnection(ConnectionContext context, ConnectionInfo info, Throwable error)
void
EmptyBroker. removeConnection(ConnectionContext context, ConnectionInfo info, Throwable error)
void
ErrorBroker. removeConnection(ConnectionContext context, ConnectionInfo info, Throwable error)
void
TransactionBroker. removeConnection(ConnectionContext context, ConnectionInfo info, Throwable error)
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)
void
BrokerBroadcaster. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
void
BrokerFilter. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
void
EmptyBroker. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
void
ErrorBroker. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
void
Broker. removeDestinationInfo(ConnectionContext context, DestinationInfo info)
Remove and process a DestinationInfo objectvoid
BrokerFilter. removeDestinationInfo(ConnectionContext context, DestinationInfo info)
void
EmptyBroker. removeDestinationInfo(ConnectionContext context, DestinationInfo info)
void
ErrorBroker. removeDestinationInfo(ConnectionContext context, DestinationInfo info)
void
Broker. removeProducer(ConnectionContext context, ProducerInfo info)
Removes a producer.void
BrokerBroadcaster. removeProducer(ConnectionContext context, ProducerInfo info)
void
BrokerFilter. removeProducer(ConnectionContext context, ProducerInfo info)
void
CompositeDestinationBroker. removeProducer(ConnectionContext context, ProducerInfo info)
A producer may de-register from sending to multiple destinations via a composite destination.void
EmptyBroker. removeProducer(ConnectionContext context, ProducerInfo info)
void
ErrorBroker. removeProducer(ConnectionContext context, ProducerInfo info)
void
Broker. removeSession(ConnectionContext context, SessionInfo info)
Removes a session.void
BrokerBroadcaster. removeSession(ConnectionContext context, SessionInfo info)
void
BrokerFilter. removeSession(ConnectionContext context, SessionInfo info)
void
EmptyBroker. removeSession(ConnectionContext context, SessionInfo info)
void
ErrorBroker. removeSession(ConnectionContext context, SessionInfo info)
void
BrokerBroadcaster. removeSubscription(ConnectionContext context, RemoveSubscriptionInfo info)
void
BrokerFilter. removeSubscription(ConnectionContext context, RemoveSubscriptionInfo info)
void
EmptyBroker. removeSubscription(ConnectionContext context, RemoveSubscriptionInfo info)
void
ErrorBroker. removeSubscription(ConnectionContext context, RemoveSubscriptionInfo info)
void
Broker. rollbackTransaction(ConnectionContext context, TransactionId xid)
Rollsback a transaction.void
BrokerBroadcaster. rollbackTransaction(ConnectionContext context, TransactionId xid)
void
BrokerFilter. rollbackTransaction(ConnectionContext context, TransactionId xid)
void
EmptyBroker. rollbackTransaction(ConnectionContext context, TransactionId xid)
void
ErrorBroker. rollbackTransaction(ConnectionContext context, TransactionId xid)
void
TransactionBroker. rollbackTransaction(ConnectionContext context, TransactionId xid)
boolean
Broker. sendToDeadLetterQueue(ConnectionContext context, MessageReference messageReference, Subscription subscription, Throwable poisonCause)
A message needs to go the a DLQboolean
BrokerFilter. sendToDeadLetterQueue(ConnectionContext context, MessageReference messageReference, Subscription subscription, Throwable poisonCause)
boolean
EmptyBroker. sendToDeadLetterQueue(ConnectionContext context, MessageReference messageReference, Subscription subscription, Throwable poisonCause)
boolean
ErrorBroker. sendToDeadLetterQueue(ConnectionContext context, MessageReference messageReference, Subscription subscription, Throwable poisonCause)
void
Broker. setAdminConnectionContext(ConnectionContext adminConnectionContext)
Sets the default administration connection context used when configuring the broker on startup or via JMXvoid
BrokerFilter. setAdminConnectionContext(ConnectionContext adminConnectionContext)
void
EmptyBroker. setAdminConnectionContext(ConnectionContext adminConnectionContext)
void
ErrorBroker. setAdminConnectionContext(ConnectionContext adminConnectionContext)
void
ConsumerBrokerExchange. setConnectionContext(ConnectionContext connectionContext)
void
ProducerBrokerExchange. setConnectionContext(ConnectionContext connectionContext)
void
TransportConnectionState. setContext(ConnectionContext context)
void
Broker. slowConsumer(ConnectionContext context, Destination destination, Subscription subs)
Called when there is a slow consumervoid
BrokerFilter. slowConsumer(ConnectionContext context, Destination destination, Subscription subs)
void
EmptyBroker. slowConsumer(ConnectionContext context, Destination destination, Subscription subs)
void
ErrorBroker. slowConsumer(ConnectionContext context, Destination destination, Subscription subs)
void
Broker. virtualDestinationAdded(ConnectionContext context, VirtualDestination virtualDestination)
void
BrokerFilter. virtualDestinationAdded(ConnectionContext context, VirtualDestination virtualDestination)
void
EmptyBroker. virtualDestinationAdded(ConnectionContext context, VirtualDestination virtualDestination)
void
ErrorBroker. virtualDestinationAdded(ConnectionContext context, VirtualDestination virtualDestination)
void
Broker. virtualDestinationRemoved(ConnectionContext context, VirtualDestination virtualDestination)
void
BrokerFilter. virtualDestinationRemoved(ConnectionContext context, VirtualDestination virtualDestination)
void
EmptyBroker. virtualDestinationRemoved(ConnectionContext context, VirtualDestination virtualDestination)
void
ErrorBroker. virtualDestinationRemoved(ConnectionContext context, VirtualDestination virtualDestination)
-
Uses of ConnectionContext in org.apache.activemq.broker.cluster
Methods in org.apache.activemq.broker.cluster with parameters of type ConnectionContext Modifier and Type Method Description Subscription
ConnectionSplitBroker. addConsumer(ConnectionContext context, ConsumerInfo info)
void
ConnectionSplitBroker. removeConsumer(ConnectionContext context, ConsumerInfo info)
-
Uses of ConnectionContext in org.apache.activemq.broker.jmx
-
Uses of ConnectionContext in org.apache.activemq.broker.region
Fields in org.apache.activemq.broker.region declared as ConnectionContext Modifier and Type Field Description protected ConnectionContext
AbstractSubscription. context
Methods in org.apache.activemq.broker.region that return ConnectionContext Modifier and Type Method Description ConnectionContext
BaseDestination. createConnectionContext()
ConnectionContext
RegionBroker. getAdminConnectionContext()
ConnectionContext
RegionBroker. getConnectionContext(String clientId)
ConnectionContext
AbstractSubscription. getContext()
ConnectionContext
Subscription. getContext()
Methods in org.apache.activemq.broker.region with parameters of type ConnectionContext Modifier and Type Method Description void
AbstractSubscription. acknowledge(ConnectionContext context, MessageAck ack)
void
Destination. acknowledge(ConnectionContext context, Subscription sub, MessageAck ack, MessageReference node)
void
DestinationFilter. acknowledge(ConnectionContext context, Subscription sub, MessageAck ack, MessageReference node)
protected void
DurableTopicSubscription. acknowledge(ConnectionContext context, MessageAck ack, MessageReference node)
void
PrefetchSubscription. acknowledge(ConnectionContext context, MessageAck ack)
protected abstract void
PrefetchSubscription. acknowledge(ConnectionContext context, MessageAck ack, MessageReference node)
Used during acknowledgment to remove the message.void
Queue. acknowledge(ConnectionContext context, Subscription sub, MessageAck ack, MessageReference node)
protected void
QueueBrowserSubscription. acknowledge(ConnectionContext context, MessageAck ack, MessageReference n)
Since we are a browser we don't really remove the message from the queue.protected void
QueueSubscription. acknowledge(ConnectionContext context, MessageAck ack, MessageReference n)
In the queue case, mark the node as dropped and then a gc cycle will remove it from the queue.void
Subscription. acknowledge(ConnectionContext context, MessageAck ack)
Used when client acknowledge receipt of dispatched message.void
Topic. acknowledge(ConnectionContext context, Subscription sub, MessageAck ack, MessageReference node)
void
TopicSubscription. acknowledge(ConnectionContext context, MessageAck ack)
void
DurableTopicSubscription. activate(SystemUsage memoryManager, ConnectionContext context, ConsumerInfo info, RegionBroker regionBroker)
void
Topic. activate(ConnectionContext context, DurableTopicSubscription subscription)
void
AbstractSubscription. add(ConnectionContext context, Destination destination)
void
DurableTopicSubscription. add(ConnectionContext context, Destination destination)
void
PrefetchSubscription. add(ConnectionContext context, Destination destination)
void
Subscription. add(ConnectionContext context, Destination destination)
The subscription will be receiving messages from the destination.void
RegionBroker. addConnection(ConnectionContext context, ConnectionInfo info)
Subscription
AbstractRegion. addConsumer(ConnectionContext context, ConsumerInfo info)
Subscription
Region. addConsumer(ConnectionContext context, ConsumerInfo info)
Adds a consumer.Subscription
RegionBroker. addConsumer(ConnectionContext context, ConsumerInfo info)
Subscription
TopicRegion. addConsumer(ConnectionContext context, ConsumerInfo info)
Destination
AbstractRegion. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean createIfTemporary)
Destination
Region. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean createIfTemporary)
Used to create a destination.Destination
RegionBroker. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean createIfTemp)
void
RegionBroker. addDestinationInfo(ConnectionContext context, DestinationInfo info)
void
AbstractRegion. addProducer(ConnectionContext context, ProducerInfo info)
void
BaseDestination. addProducer(ConnectionContext context, ProducerInfo info)
void
Destination. addProducer(ConnectionContext context, ProducerInfo info)
void
DestinationFilter. addProducer(ConnectionContext context, ProducerInfo info)
void
Region. addProducer(ConnectionContext context, ProducerInfo info)
Adds a Producer.void
RegionBroker. addProducer(ConnectionContext context, ProducerInfo info)
boolean
AbstractSubscription. addRecoveredMessage(ConnectionContext context, MessageReference message)
boolean
SubscriptionRecovery. addRecoveredMessage(ConnectionContext context, MessageReference message)
Add a message to the SubscriptionRecoveryvoid
BaseDestination. addSubscription(ConnectionContext context, Subscription sub)
void
Destination. addSubscription(ConnectionContext context, Subscription sub)
void
DestinationFilter. addSubscription(ConnectionContext context, Subscription sub)
void
Queue. addSubscription(ConnectionContext context, Subscription sub)
void
TempQueue. addSubscription(ConnectionContext context, Subscription sub)
void
TempTopic. addSubscription(ConnectionContext context, Subscription sub)
void
Topic. addSubscription(ConnectionContext context, Subscription sub)
protected List<Subscription>
AbstractRegion. addSubscriptionsForDestination(ConnectionContext context, Destination dest)
protected List<Subscription>
TopicRegion. addSubscriptionsForDestination(ConnectionContext context, Destination dest)
void
RegionBroker. beginTransaction(ConnectionContext context, TransactionId xid)
void
RegionBroker. commitTransaction(ConnectionContext context, TransactionId xid, boolean onePhase)
int
Queue. copyMatchingMessages(ConnectionContext context, MessageReferenceFilter filter, ActiveMQDestination dest, int maximumMessages)
Copies the messages matching the given filter up to the maximum number of matched messagesint
Queue. copyMatchingMessagesTo(ConnectionContext context, String selector, ActiveMQDestination dest)
Copies the messages matching the given selectorint
Queue. copyMatchingMessagesTo(ConnectionContext context, String selector, ActiveMQDestination dest, int maximumMessages)
Copies the messages matching the given selector up to the maximum number of matched messagesboolean
Queue. copyMessageTo(ConnectionContext context, String messageId, ActiveMQDestination dest)
Copies the message matching the given messageIdvoid
CompositeDestinationInterceptor. create(Broker broker, ConnectionContext context, ActiveMQDestination destination)
void
DestinationInterceptor. create(Broker broker, ConnectionContext context, ActiveMQDestination destination)
protected Destination
AbstractRegion. createDestination(ConnectionContext context, ActiveMQDestination destination)
protected Destination
AbstractTempRegion. createDestination(ConnectionContext context, ActiveMQDestination destination)
abstract Destination
DestinationFactory. createDestination(ConnectionContext context, ActiveMQDestination destination, DestinationStatistics destinationStatistics)
Create destination implementation.Destination
DestinationFactoryImpl. createDestination(ConnectionContext context, ActiveMQDestination destination, DestinationStatistics destinationStatistics)
protected abstract Subscription
AbstractRegion. createSubscription(ConnectionContext context, ConsumerInfo info)
protected Subscription
QueueRegion. createSubscription(ConnectionContext context, ConsumerInfo info)
protected Subscription
TempQueueRegion. createSubscription(ConnectionContext context, ConsumerInfo info)
protected Subscription
TempTopicRegion. createSubscription(ConnectionContext context, ConsumerInfo info)
protected Subscription
TopicRegion. createSubscription(ConnectionContext context, ConsumerInfo info)
void
Topic. deactivate(ConnectionContext context, DurableTopicSubscription sub, List<MessageReference> dispatched)
void
DestinationFilter. deleteSubscription(ConnectionContext context, SubscriptionKey key)
void
Topic. deleteSubscription(ConnectionContext context, SubscriptionKey key)
protected void
Topic. dispatch(ConnectionContext context, Message message)
protected void
AbstractRegion. dispose(ConnectionContext context, Destination dest)
protected void
AbstractTempRegion. dispose(ConnectionContext context, Destination dest)
void
BaseDestination. dispose(ConnectionContext context)
void
Destination. dispose(ConnectionContext context)
void
DestinationFilter. dispose(ConnectionContext context)
void
TempQueue. dispose(ConnectionContext context)
protected void
Queue. doBrowseList(List<Message> browseList, int max, PendingList list, ReentrantReadWriteLock lock, ConnectionContext connectionContext, String name)
boolean
MessageReferenceFilter. evaluate(ConnectionContext context, MessageReference messageReference)
void
BaseDestination. fastProducer(ConnectionContext context, ProducerInfo producerInfo)
Called to notify a producer is too fastvoid
Destination. fastProducer(ConnectionContext context, ProducerInfo producerInfo)
Called to notify a producer is too fastvoid
DestinationFilter. fastProducer(ConnectionContext context, ProducerInfo producerInfo)
void
RegionBroker. forgetTransaction(ConnectionContext context, TransactionId transactionId)
TransactionId[]
RegionBroker. getPreparedTransactions(ConnectionContext context)
void
BaseDestination. isFull(ConnectionContext context, Usage<?> usage)
Called when a Usage reaches a limitvoid
Destination. isFull(ConnectionContext context, Usage<?> usage)
Called when a Usage reaches a limitvoid
DestinationFilter. isFull(ConnectionContext context, Usage<?> usage)
protected Destination
AbstractRegion. lookup(ConnectionContext context, ActiveMQDestination destination, boolean createTemporary)
void
BaseDestination. messageConsumed(ConnectionContext context, MessageReference messageReference)
called when message is consumedvoid
Destination. messageConsumed(ConnectionContext context, MessageReference messageReference)
called when message is consumedvoid
DestinationFilter. messageConsumed(ConnectionContext context, MessageReference messageReference)
void
BaseDestination. messageDelivered(ConnectionContext context, MessageReference messageReference)
Called when message is delivered to the brokervoid
Destination. messageDelivered(ConnectionContext context, MessageReference messageReference)
Called when message is delivered to the brokervoid
DestinationFilter. messageDelivered(ConnectionContext context, MessageReference messageReference)
void
BaseDestination. messageDiscarded(ConnectionContext context, Subscription sub, MessageReference messageReference)
Called when a message is discarded - e.g.void
Destination. messageDiscarded(ConnectionContext context, Subscription sub, MessageReference messageReference)
Called when a message is discarded - e.g.void
DestinationFilter. messageDiscarded(ConnectionContext context, Subscription sub, MessageReference messageReference)
void
Destination. messageExpired(ConnectionContext context, Subscription subs, MessageReference node)
Inform the Destination a message has expiredvoid
DestinationFilter. messageExpired(ConnectionContext context, PrefetchSubscription prefetchSubscription, MessageReference node)
void
DestinationFilter. messageExpired(ConnectionContext context, Subscription subs, MessageReference node)
void
Queue. messageExpired(ConnectionContext context, MessageReference reference)
void
Queue. messageExpired(ConnectionContext context, Subscription subs, MessageReference reference)
void
RegionBroker. messageExpired(ConnectionContext context, MessageReference node, Subscription subscription)
void
Topic. messageExpired(ConnectionContext context, Subscription subs, MessageReference reference)
Response
AbstractRegion. messagePull(ConnectionContext context, MessagePull pull)
Response
Region. messagePull(ConnectionContext context, MessagePull pull)
Allows a consumer to pull a message from a queueResponse
RegionBroker. messagePull(ConnectionContext context, MessagePull pull)
int
Queue. moveMatchingMessagesTo(ConnectionContext context, String selector, ActiveMQDestination dest)
Moves the messages matching the given selectorint
Queue. moveMatchingMessagesTo(ConnectionContext context, String selector, ActiveMQDestination dest, int maximumMessages)
Moves the messages matching the given selector up to the maximum number of matched messagesint
Queue. moveMatchingMessagesTo(ConnectionContext context, MessageReferenceFilter filter, ActiveMQDestination dest, int maximumMessages)
Moves the messages matching the given filter up to the maximum number of matched messagesboolean
Queue. moveMessageTo(ConnectionContext context, String messageId, ActiveMQDestination dest)
Moves the message matching the given messageIdboolean
Queue. moveMessageTo(ConnectionContext context, QueueMessageReference m, ActiveMQDestination dest)
Move a messageprotected void
BaseDestination. onMessageWithNoConsumers(ConnectionContext context, Message msg)
Provides a hook to allow messages with no consumer to be processed in some way - such as to send to a dead letter queue or something..int
RegionBroker. prepareTransaction(ConnectionContext context, TransactionId xid)
Response
PrefetchSubscription. pullMessage(ConnectionContext context, MessagePull pull)
Allows a message to be pulled on demand by a clientResponse
Subscription. pullMessage(ConnectionContext context, MessagePull pull)
Allows a consumer to pull a message on demandResponse
TopicSubscription. pullMessage(ConnectionContext context, MessagePull pull)
void
Topic. recoverRetroactiveMessages(ConnectionContext context, Subscription subscription)
List<MessageReference>
AbstractSubscription. remove(ConnectionContext context, Destination destination)
List<MessageReference>
PrefetchSubscription. remove(ConnectionContext context, Destination destination)
List<MessageReference>
PrefetchSubscription. remove(ConnectionContext context, Destination destination, List<MessageReference> dispatched)
List<MessageReference>
QueueBrowserSubscription. remove(ConnectionContext context, Destination destination)
List<MessageReference>
Subscription. remove(ConnectionContext context, Destination destination)
The subscription will be no longer be receiving messages from the destination.void
RegionBroker. removeConnection(ConnectionContext context, ConnectionInfo info, Throwable error)
void
AbstractRegion. removeConsumer(ConnectionContext context, ConsumerInfo info)
void
Region. removeConsumer(ConnectionContext context, ConsumerInfo info)
Removes a consumer.void
RegionBroker. removeConsumer(ConnectionContext context, ConsumerInfo info)
void
TopicRegion. removeConsumer(ConnectionContext context, ConsumerInfo info)
void
AbstractRegion. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
void
Region. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
Used to destroy a destination.void
RegionBroker. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
void
TempQueueRegion. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
void
TempTopicRegion. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
void
RegionBroker. removeDestinationInfo(ConnectionContext context, DestinationInfo info)
protected void
Queue. removeMessage(ConnectionContext c, QueueMessageReference r)
protected void
Queue. removeMessage(ConnectionContext c, Subscription subs, QueueMessageReference r)
protected void
Queue. removeMessage(ConnectionContext context, Subscription sub, QueueMessageReference reference, MessageAck ack)
void
AbstractRegion. removeProducer(ConnectionContext context, ProducerInfo info)
Removes a Producer.void
BaseDestination. removeProducer(ConnectionContext context, ProducerInfo info)
void
Destination. removeProducer(ConnectionContext context, ProducerInfo info)
void
DestinationFilter. removeProducer(ConnectionContext context, ProducerInfo info)
void
Region. removeProducer(ConnectionContext context, ProducerInfo info)
Removes a Producer.void
RegionBroker. removeProducer(ConnectionContext context, ProducerInfo info)
void
AbstractRegion. removeSubscription(ConnectionContext context, RemoveSubscriptionInfo info)
void
BaseDestination. removeSubscription(ConnectionContext context, Subscription sub, long lastDeliveredSequenceId)
void
Destination. removeSubscription(ConnectionContext context, Subscription sub, long lastDeliveredSequenceId)
void
DestinationFilter. removeSubscription(ConnectionContext context, Subscription sub, long lastDeliveredSequenceId)
void
Queue. removeSubscription(ConnectionContext context, Subscription sub, long lastDeliveredSequenceId)
void
Region. removeSubscription(ConnectionContext context, RemoveSubscriptionInfo info)
Deletes a durable subscription.void
RegionBroker. removeSubscription(ConnectionContext context, RemoveSubscriptionInfo info)
void
Topic. removeSubscription(ConnectionContext context, Subscription sub, long lastDeliveredSequenceId)
void
TopicRegion. removeSubscription(ConnectionContext context, RemoveSubscriptionInfo info)
int
Queue. retryMessages(ConnectionContext context, int maximumMessages)
void
RegionBroker. rollbackTransaction(ConnectionContext context, TransactionId xid)
boolean
RegionBroker. sendToDeadLetterQueue(ConnectionContext context, MessageReference node, Subscription subscription, Throwable poisonCause)
protected void
PrefetchSubscription. sendToDLQ(ConnectionContext context, MessageReference node, Throwable poisonCause)
void
RegionBroker. setAdminConnectionContext(ConnectionContext adminConnectionContext)
void
BaseDestination. slowConsumer(ConnectionContext context, Subscription subs)
Called when there is a slow consumervoid
Destination. slowConsumer(ConnectionContext context, Subscription subs)
Called when there is a slow consumervoid
DestinationFilter. slowConsumer(ConnectionContext context, Subscription subs)
protected void
BaseDestination. waitForSpace(ConnectionContext context, ProducerBrokerExchange producerBrokerExchange, Usage<?> usage, int highWaterMark, String warning)
protected void
BaseDestination. waitForSpace(ConnectionContext context, ProducerBrokerExchange producerBrokerExchange, Usage<?> usage, String warning)
Constructors in org.apache.activemq.broker.region with parameters of type ConnectionContext 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 ConnectionContext in org.apache.activemq.broker.region.cursors
Methods in org.apache.activemq.broker.region.cursors with parameters of type ConnectionContext Modifier and Type Method Description void
AbstractPendingMessageCursor. add(ConnectionContext context, Destination destination)
void
PendingMessageCursor. add(ConnectionContext context, Destination destination)
Add a destinationvoid
StoreDurableSubscriberCursor. add(ConnectionContext context, Destination destination)
Add a destinationList<MessageReference>
AbstractPendingMessageCursor. remove(ConnectionContext context, Destination destination)
List<MessageReference>
PendingMessageCursor. remove(ConnectionContext context, Destination destination)
remove a destinationList<MessageReference>
StoreDurableSubscriberCursor. remove(ConnectionContext context, Destination destination)
remove a destinationList<MessageReference>
VMPendingMessageCursor. remove(ConnectionContext context, Destination destination)
-
Uses of ConnectionContext in org.apache.activemq.broker.region.policy
Methods in org.apache.activemq.broker.region.policy with parameters of type ConnectionContext Modifier and Type Method Description boolean
FixedCountSubscriptionRecoveryPolicy. add(ConnectionContext context, MessageReference node)
boolean
FixedSizedSubscriptionRecoveryPolicy. add(ConnectionContext context, MessageReference message)
boolean
LastImageSubscriptionRecoveryPolicy. add(ConnectionContext context, MessageReference node)
boolean
NoSubscriptionRecoveryPolicy. add(ConnectionContext context, MessageReference node)
boolean
QueryBasedSubscriptionRecoveryPolicy. add(ConnectionContext context, MessageReference message)
boolean
RetainedMessageSubscriptionRecoveryPolicy. add(ConnectionContext context, MessageReference node)
boolean
SubscriptionRecoveryPolicy. add(ConnectionContext context, MessageReference message)
A message was sent to the destination.boolean
TimedSubscriptionRecoveryPolicy. add(ConnectionContext context, MessageReference message)
protected void
QueryBasedSubscriptionRecoveryPolicy. dispatchInitialMessage(Message message, Destination regionDestination, ConnectionContext context, SubscriptionRecovery sub)
void
FixedCountSubscriptionRecoveryPolicy. recover(ConnectionContext context, Topic topic, SubscriptionRecovery sub)
void
FixedSizedSubscriptionRecoveryPolicy. recover(ConnectionContext context, Topic topic, SubscriptionRecovery sub)
void
LastImageSubscriptionRecoveryPolicy. recover(ConnectionContext context, Topic topic, SubscriptionRecovery sub)
void
NoSubscriptionRecoveryPolicy. recover(ConnectionContext context, Topic topic, SubscriptionRecovery sub)
void
QueryBasedSubscriptionRecoveryPolicy. recover(ConnectionContext context, Topic topic, SubscriptionRecovery sub)
void
RetainedMessageSubscriptionRecoveryPolicy. recover(ConnectionContext context, Topic topic, SubscriptionRecovery sub)
void
SubscriptionRecoveryPolicy. recover(ConnectionContext context, Topic topic, SubscriptionRecovery sub)
Let a subscription recover message held by the policy.void
TimedSubscriptionRecoveryPolicy. recover(ConnectionContext context, Topic topic, SubscriptionRecovery sub)
void
AbortSlowAckConsumerStrategy. slowConsumer(ConnectionContext context, Subscription subs)
void
AbortSlowConsumerStrategy. slowConsumer(ConnectionContext context, Subscription subs)
void
SlowConsumerStrategy. slowConsumer(ConnectionContext context, Subscription subs)
Slow consumer event. -
Uses of ConnectionContext in org.apache.activemq.broker.region.virtual
Methods in org.apache.activemq.broker.region.virtual with parameters of type ConnectionContext Modifier and Type Method Description void
MappedQueueFilter. addSubscription(ConnectionContext context, Subscription sub)
void
CompositeDestination. create(Broker broker, ConnectionContext context, ActiveMQDestination destination)
void
MirroredQueue. create(Broker broker, ConnectionContext context, ActiveMQDestination destination)
void
VirtualDestinationInterceptor. create(Broker broker, ConnectionContext context, ActiveMQDestination destination)
void
VirtualTopic. create(Broker broker, ConnectionContext context, ActiveMQDestination destination)
void
MappedQueueFilter. deleteSubscription(ConnectionContext context, SubscriptionKey key)
void
MappedQueueFilter. removeSubscription(ConnectionContext context, Subscription sub, long lastDeliveredSequenceId)
-
Uses of ConnectionContext in org.apache.activemq.broker.scheduler
Methods in org.apache.activemq.broker.scheduler with parameters of type ConnectionContext Modifier and Type Method Description protected void
SchedulerBroker. sendScheduledJob(ConnectionContext context, Job job, ActiveMQDestination replyTo)
-
Uses of ConnectionContext in org.apache.activemq.broker.util
Methods in org.apache.activemq.broker.util with parameters of type ConnectionContext Modifier and Type Method Description void
LoggingBrokerPlugin. addConnection(ConnectionContext context, ConnectionInfo info)
void
UDPTraceBrokerPlugin. addConnection(ConnectionContext context, ConnectionInfo info)
Subscription
DestinationPathSeparatorBroker. addConsumer(ConnectionContext context, ConsumerInfo info)
Subscription
LoggingBrokerPlugin. addConsumer(ConnectionContext context, ConsumerInfo info)
Subscription
UDPTraceBrokerPlugin. addConsumer(ConnectionContext context, ConsumerInfo info)
Destination
DestinationPathSeparatorBroker. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean createIfTemporary)
Destination
DestinationsPlugin. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean createIfTemporary)
Destination
LoggingBrokerPlugin. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean create)
void
DestinationPathSeparatorBroker. addDestinationInfo(ConnectionContext context, DestinationInfo info)
void
LoggingBrokerPlugin. addDestinationInfo(ConnectionContext context, DestinationInfo info)
void
UDPTraceBrokerPlugin. addDestinationInfo(ConnectionContext context, DestinationInfo info)
void
DestinationPathSeparatorBroker. addProducer(ConnectionContext context, ProducerInfo info)
void
LoggingBrokerPlugin. addProducer(ConnectionContext context, ProducerInfo info)
void
UDPTraceBrokerPlugin. addProducer(ConnectionContext context, ProducerInfo info)
void
LoggingBrokerPlugin. addSession(ConnectionContext context, SessionInfo info)
void
UDPTraceBrokerPlugin. addSession(ConnectionContext context, SessionInfo info)
void
LoggingBrokerPlugin. beginTransaction(ConnectionContext context, TransactionId xid)
void
UDPTraceBrokerPlugin. beginTransaction(ConnectionContext context, TransactionId xid)
void
LoggingBrokerPlugin. commitTransaction(ConnectionContext context, TransactionId xid, boolean onePhase)
void
UDPTraceBrokerPlugin. commitTransaction(ConnectionContext context, TransactionId xid, boolean onePhase)
void
LoggingBrokerPlugin. fastProducer(ConnectionContext context, ProducerInfo producerInfo, ActiveMQDestination destination)
void
LoggingBrokerPlugin. forgetTransaction(ConnectionContext context, TransactionId transactionId)
void
UDPTraceBrokerPlugin. forgetTransaction(ConnectionContext context, TransactionId xid)
TransactionId[]
LoggingBrokerPlugin. getPreparedTransactions(ConnectionContext context)
void
LoggingBrokerPlugin. isFull(ConnectionContext context, Destination destination, Usage<?> usage)
void
LoggingBrokerPlugin. messageConsumed(ConnectionContext context, MessageReference messageReference)
void
LoggingBrokerPlugin. messageDelivered(ConnectionContext context, MessageReference messageReference)
void
LoggingBrokerPlugin. messageDiscarded(ConnectionContext context, Subscription sub, MessageReference messageReference)
void
LoggingBrokerPlugin. messageExpired(ConnectionContext context, MessageReference message, Subscription subscription)
Response
DestinationPathSeparatorBroker. messagePull(ConnectionContext context, MessagePull pull)
Response
LoggingBrokerPlugin. messagePull(ConnectionContext context, MessagePull pull)
Response
UDPTraceBrokerPlugin. messagePull(ConnectionContext context, MessagePull pull)
int
LoggingBrokerPlugin. prepareTransaction(ConnectionContext context, TransactionId xid)
int
UDPTraceBrokerPlugin. prepareTransaction(ConnectionContext context, TransactionId xid)
void
LoggingBrokerPlugin. removeConnection(ConnectionContext context, ConnectionInfo info, Throwable error)
void
UDPTraceBrokerPlugin. removeConnection(ConnectionContext context, ConnectionInfo info, Throwable error)
void
DestinationPathSeparatorBroker. removeConsumer(ConnectionContext context, ConsumerInfo info)
void
LoggingBrokerPlugin. removeConsumer(ConnectionContext context, ConsumerInfo info)
void
UDPTraceBrokerPlugin. removeConsumer(ConnectionContext context, ConsumerInfo info)
void
DestinationPathSeparatorBroker. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
void
DestinationsPlugin. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
void
LoggingBrokerPlugin. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
void
UDPTraceBrokerPlugin. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
void
DestinationPathSeparatorBroker. removeDestinationInfo(ConnectionContext context, DestinationInfo info)
void
LoggingBrokerPlugin. removeDestinationInfo(ConnectionContext context, DestinationInfo info)
void
UDPTraceBrokerPlugin. removeDestinationInfo(ConnectionContext context, DestinationInfo info)
void
DestinationPathSeparatorBroker. removeProducer(ConnectionContext context, ProducerInfo info)
void
LoggingBrokerPlugin. removeProducer(ConnectionContext context, ProducerInfo info)
void
UDPTraceBrokerPlugin. removeProducer(ConnectionContext context, ProducerInfo info)
void
LoggingBrokerPlugin. removeSession(ConnectionContext context, SessionInfo info)
void
UDPTraceBrokerPlugin. removeSession(ConnectionContext context, SessionInfo info)
void
LoggingBrokerPlugin. removeSubscription(ConnectionContext context, RemoveSubscriptionInfo info)
void
UDPTraceBrokerPlugin. removeSubscription(ConnectionContext context, RemoveSubscriptionInfo info)
void
LoggingBrokerPlugin. rollbackTransaction(ConnectionContext context, TransactionId xid)
void
UDPTraceBrokerPlugin. rollbackTransaction(ConnectionContext context, TransactionId xid)
boolean
LoggingBrokerPlugin. sendToDeadLetterQueue(ConnectionContext context, MessageReference messageReference, Subscription subscription, Throwable poisonCause)
boolean
RedeliveryPlugin. sendToDeadLetterQueue(ConnectionContext context, MessageReference messageReference, Subscription subscription, Throwable poisonCause)
void
LoggingBrokerPlugin. slowConsumer(ConnectionContext context, Destination destination, Subscription subs)
-
Uses of ConnectionContext in org.apache.activemq.broker.view
Methods in org.apache.activemq.broker.view with parameters of type ConnectionContext Modifier and Type Method Description Subscription
ConnectionDotFileInterceptor. addConsumer(ConnectionContext context, ConsumerInfo info)
Destination
DestinationDotFileInterceptor. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean create)
void
ConnectionDotFileInterceptor. addProducer(ConnectionContext context, ProducerInfo info)
void
ConnectionDotFileInterceptor. removeConsumer(ConnectionContext context, ConsumerInfo info)
void
DestinationDotFileInterceptor. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
void
ConnectionDotFileInterceptor. removeProducer(ConnectionContext context, ProducerInfo info)
-
Uses of ConnectionContext in org.apache.activemq.partition
Methods in org.apache.activemq.partition with parameters of type ConnectionContext Modifier and Type Method Description void
PartitionBroker. addConnection(ConnectionContext context, ConnectionInfo info)
void
PartitionBroker. removeConnection(ConnectionContext context, ConnectionInfo info, Throwable error)
-
Uses of ConnectionContext in org.apache.activemq.plugin
Methods in org.apache.activemq.plugin with parameters of type ConnectionContext Modifier and Type Method Description void
AbstractRuntimeConfigurationBroker. addConnection(ConnectionContext context, ConnectionInfo info)
Subscription
SubQueueSelectorCacheBroker. addConsumer(ConnectionContext context, ConsumerInfo info)
Destination
AbstractRuntimeConfigurationBroker. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean createIfTemporary)
void
SubQueueSelectorCacheBroker. removeConsumer(ConnectionContext context, ConsumerInfo info)
protected void
StatisticsBroker. sendStats(ConnectionContext context, ActiveMQMapMessage msg, ActiveMQDestination replyTo)
protected void
StatisticsBroker. sendSubStats(ConnectionContext context, ObjectName[] subscribers, ActiveMQDestination replyTo)
boolean
DiscardingDLQBroker. sendToDeadLetterQueue(ConnectionContext ctx, MessageReference msgRef, Subscription subscription, Throwable poisonCause)
-
Uses of ConnectionContext in org.apache.activemq.security
Methods in org.apache.activemq.security with parameters of type ConnectionContext Modifier and Type Method Description void
JaasAuthenticationBroker. addConnection(ConnectionContext context, ConnectionInfo info)
void
JaasCertificateAuthenticationBroker. addConnection(ConnectionContext context, ConnectionInfo info)
Overridden to allow for authentication based on client certificates.void
JaasDualAuthenticationBroker. addConnection(ConnectionContext context, ConnectionInfo info)
Overridden to allow for authentication using different Jaas configurations depending on if the connection is SSL or not.void
SimpleAuthenticationBroker. addConnection(ConnectionContext context, ConnectionInfo info)
Subscription
AuthorizationBroker. addConsumer(ConnectionContext context, ConsumerInfo info)
Destination
AuthorizationBroker. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean create)
void
AuthorizationBroker. addDestinationInfo(ConnectionContext context, DestinationInfo info)
void
AuthorizationBroker. addProducer(ConnectionContext context, ProducerInfo info)
void
AuthorizationDestinationFilter. addSubscription(ConnectionContext context, Subscription sub)
protected SecurityContext
AuthorizationBroker. checkSecurityContext(ConnectionContext context)
void
AuthorizationDestinationInterceptor. create(Broker broker, ConnectionContext context, ActiveMQDestination destination)
boolean
MessageAuthorizationPolicy. isAllowedToConsume(ConnectionContext context, Message message)
Returns true if the given message is able to be dispatched to the connection performing any uservoid
AbstractAuthenticationBroker. removeConnection(ConnectionContext context, ConnectionInfo info, Throwable error)
void
JaasCertificateAuthenticationBroker. removeConnection(ConnectionContext context, ConnectionInfo info, Throwable error)
Overriding removeConnection to make sure the security context is cleaned.void
JaasDualAuthenticationBroker. removeConnection(ConnectionContext context, ConnectionInfo info, Throwable error)
Overriding removeConnection to make sure the security context is cleaned.void
AbstractAuthenticationBroker. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
void
AuthorizationBroker. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
void
JaasDualAuthenticationBroker. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
void
AuthorizationBroker. removeDestinationInfo(ConnectionContext context, DestinationInfo info)
-
Uses of ConnectionContext in org.apache.activemq.shiro
Methods in org.apache.activemq.shiro that return ConnectionContext Modifier and Type Method Description ConnectionContext
ConnectionReference. getConnectionContext()
Constructors in org.apache.activemq.shiro with parameters of type ConnectionContext Constructor Description ConnectionReference(ConnectionContext connCtx, ConnectionInfo connInfo, org.apache.shiro.env.Environment environment)
-
Uses of ConnectionContext in org.apache.activemq.shiro.authc
Methods in org.apache.activemq.shiro.authc with parameters of type ConnectionContext Modifier and Type Method Description void
AuthenticationFilter. addConnection(ConnectionContext context, ConnectionInfo info)
void
AuthenticationFilter. removeConnection(ConnectionContext context, ConnectionInfo info, Throwable error)
-
Uses of ConnectionContext in org.apache.activemq.shiro.authz
Methods in org.apache.activemq.shiro.authz that return ConnectionContext Modifier and Type Method Description ConnectionContext
DestinationAction. getConnectionContext()
Methods in org.apache.activemq.shiro.authz with parameters of type ConnectionContext Modifier and Type Method Description Subscription
AuthorizationFilter. addConsumer(ConnectionContext context, ConsumerInfo info)
Destination
AuthorizationFilter. addDestination(ConnectionContext context, ActiveMQDestination destination, boolean create)
void
AuthorizationFilter. addDestinationInfo(ConnectionContext context, DestinationInfo info)
void
AuthorizationFilter. addProducer(ConnectionContext context, ProducerInfo info)
protected org.apache.shiro.subject.Subject
AuthorizationFilter. getSubject(ConnectionContext ctx)
Returns theSubject
associated with the specified connection using aConnectionSubjectResolver
.void
AuthorizationFilter. removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
void
AuthorizationFilter. removeDestinationInfo(ConnectionContext context, DestinationInfo info)
Constructors in org.apache.activemq.shiro.authz with parameters of type ConnectionContext Constructor Description DestinationAction(ConnectionContext connectionContext, ActiveMQDestination destination, String verb)
-
Uses of ConnectionContext in org.apache.activemq.shiro.subject
Methods in org.apache.activemq.shiro.subject with parameters of type ConnectionContext Modifier and Type Method Description void
SubjectFilter. addConnection(ConnectionContext context, ConnectionInfo info)
Creates aSubject
instance reflecting the specified Connection.void
SubjectFilter. removeConnection(ConnectionContext context, ConnectionInfo info, Throwable error)
Constructors in org.apache.activemq.shiro.subject with parameters of type ConnectionContext Constructor Description ConnectionSubjectResolver(ConnectionContext connCtx)
SubjectConnectionReference(ConnectionContext connCtx, ConnectionInfo connInfo, org.apache.shiro.env.Environment environment, org.apache.shiro.subject.Subject subject)
-
Uses of ConnectionContext in org.apache.activemq.store
Fields in org.apache.activemq.store declared as ConnectionContext Modifier and Type Field Description ConnectionContext
IndexListener.MessageContext. context
Methods in org.apache.activemq.store with parameters of type ConnectionContext Modifier and Type Method Description void
ProxyTopicMessageStore. acknowledge(ConnectionContext context, String clientId, String subscriptionName, MessageId messageId, MessageAck ack)
void
TopicMessageStore. acknowledge(ConnectionContext context, String clientId, String subscriptionName, MessageId messageId, MessageAck ack)
Stores the last acknowledged messgeID for the given subscription so that we can recover and commence dispatching messages from the last checkpointboolean
TopicReferenceStore. acknowledgeReference(ConnectionContext context, String clientId, String subscriptionName, MessageId messageId)
Removes the last acknowledged messgeID for the given subscription so that we can recover and commence dispatching messages from the last checkpoint N.B.void
AbstractMessageStore. addMessage(ConnectionContext context, Message message, boolean canOptimizeHint)
void
MessageStore. addMessage(ConnectionContext context, Message message)
Adds a message to the message storevoid
MessageStore. addMessage(ConnectionContext context, Message message, boolean canOptimizeHint)
Adds a message to the message storevoid
ProxyMessageStore. addMessage(ConnectionContext context, Message message)
void
ProxyMessageStore. addMessage(ConnectionContext context, Message message, boolean canOptimizeHint)
void
ProxyTopicMessageStore. addMessage(ConnectionContext context, Message message)
void
ProxyTopicMessageStore. addMessage(ConnectionContext context, Message message, boolean canOptimizeHint)
boolean
ReferenceStore. addMessageReference(ConnectionContext context, MessageId messageId, ReferenceStore.ReferenceData data)
Adds a message reference to the message storeListenableFuture<Object>
AbstractMessageStore. asyncAddQueueMessage(ConnectionContext context, Message message)
ListenableFuture<Object>
AbstractMessageStore. asyncAddQueueMessage(ConnectionContext context, Message message, boolean canOptimizeHint)
ListenableFuture<Object>
MessageStore. asyncAddQueueMessage(ConnectionContext context, Message message)
Adds a message to the message storeListenableFuture<Object>
MessageStore. asyncAddQueueMessage(ConnectionContext context, Message message, boolean canOptimizeHint)
Adds a message to the message storeListenableFuture<Object>
ProxyMessageStore. asyncAddQueueMessage(ConnectionContext context, Message message)
ListenableFuture<Object>
ProxyMessageStore. asyncAddQueueMessage(ConnectionContext context, Message message, boolean canOptimizeHint)
ListenableFuture<Object>
ProxyTopicMessageStore. asyncAddQueueMessage(ConnectionContext context, Message message)
ListenableFuture<Object>
ProxyTopicMessageStore. asyncAddQueueMessage(ConnectionContext context, Message message, boolean canOptimizeHint)
ListenableFuture<Object>
AbstractMessageStore. asyncAddTopicMessage(ConnectionContext context, Message message)
ListenableFuture<Object>
AbstractMessageStore. asyncAddTopicMessage(ConnectionContext context, Message message, boolean canOptimizeHint)
ListenableFuture<Object>
MessageStore. asyncAddTopicMessage(ConnectionContext context, Message message)
Adds a message to the message storeListenableFuture<Object>
MessageStore. asyncAddTopicMessage(ConnectionContext context, Message message, boolean canOptimizeHint)
Adds a message to the message storeListenableFuture<Object>
ProxyMessageStore. asyncAddTopicMessage(ConnectionContext context, Message message)
ListenableFuture<Object>
ProxyMessageStore. asyncAddTopicMessage(ConnectionContext context, Message message, boolean canOptimizeHint)
ListenableFuture<Object>
ProxyTopicMessageStore. asyncAddTopicMessage(ConnectionContext context, Message message)
ListenableFuture<Object>
ProxyTopicMessageStore. asyncAddTopicMessage(ConnectionContext context, Message message, boolean canOptimizeHint)
void
PersistenceAdapter. beginTransaction(ConnectionContext context)
This method starts a transaction on the persistent storage - which is nothing to do with JMS or XA transactions - its purely a mechanism to perform multiple writes to a persistent store in 1 transaction as a performance optimization.void
PersistenceAdapter. commitTransaction(ConnectionContext context)
Commit a persistence transactionvoid
AbstractMessageStore. dispose(ConnectionContext context)
void
MessageStore. dispose(ConnectionContext context)
void
ProxyMessageStore. dispose(ConnectionContext context)
void
ProxyTopicMessageStore. dispose(ConnectionContext context)
void
MessageStore. removeAllMessages(ConnectionContext context)
Removes all the messages from the message store.void
ProxyMessageStore. removeAllMessages(ConnectionContext context)
void
ProxyTopicMessageStore. removeAllMessages(ConnectionContext context)
void
AbstractMessageStore. removeAsyncMessage(ConnectionContext context, MessageAck ack)
void
MessageStore. removeAsyncMessage(ConnectionContext context, MessageAck ack)
void
ProxyMessageStore. removeAsyncMessage(ConnectionContext context, MessageAck ack)
void
ProxyTopicMessageStore. removeAsyncMessage(ConnectionContext context, MessageAck ack)
void
MessageStore. removeMessage(ConnectionContext context, MessageAck ack)
Removes a message from the message store.void
ProxyMessageStore. removeMessage(ConnectionContext context, MessageAck ack)
void
ProxyTopicMessageStore. removeMessage(ConnectionContext context, MessageAck ack)
void
PersistenceAdapter. rollbackTransaction(ConnectionContext context)
Rollback a persistence transactionConstructors in org.apache.activemq.store with parameters of type ConnectionContext Constructor Description MessageContext(ConnectionContext context, Message message, Runnable onCompletion)
-
Uses of ConnectionContext in org.apache.activemq.store.jdbc
Methods in org.apache.activemq.store.jdbc with parameters of type ConnectionContext Modifier and Type Method Description void
JDBCTopicMessageStore. acknowledge(ConnectionContext context, String clientId, String subscriptionName, MessageId messageId, MessageAck ack)
void
JDBCMessageStore. addMessage(ConnectionContext context, Message message)
void
JDBCMessageStore. addMessageReference(ConnectionContext context, MessageId messageId, long expirationTime, String messageRef)
void
JDBCPersistenceAdapter. beginTransaction(ConnectionContext context)
void
JDBCPersistenceAdapter. commitAdd(ConnectionContext context, MessageId messageId, long preparedSequenceId, long newSequence)
void
JDBCPersistenceAdapter. commitLastAck(ConnectionContext context, long xidLastAck, long priority, ActiveMQDestination destination, String subName, String clientId)
void
JDBCPersistenceAdapter. commitRemove(ConnectionContext context, MessageAck ack)
void
JDBCPersistenceAdapter. commitTransaction(ConnectionContext context)
TransactionContext
JDBCPersistenceAdapter. getTransactionContext(ConnectionContext context)
void
JDBCMessageStore. removeAllMessages(ConnectionContext context)
void
JDBCMessageStore. removeMessage(ConnectionContext context, MessageAck ack)
void
JDBCPersistenceAdapter. rollbackLastAck(ConnectionContext context, byte priority, ActiveMQDestination destination, String subName, String clientId)
void
JDBCPersistenceAdapter. rollbackLastAck(ConnectionContext context, JDBCTopicMessageStore store, MessageAck ack, String subName, String clientId)
void
JDBCPersistenceAdapter. rollbackTransaction(ConnectionContext context)
-
Uses of ConnectionContext in org.apache.activemq.store.journal
Methods in org.apache.activemq.store.journal with parameters of type ConnectionContext Modifier and Type Method Description void
JournalTopicMessageStore. acknowledge(ConnectionContext context, String clientId, String subscriptionName, MessageId messageId, MessageAck originalAck)
void
JournalMessageStore. addMessage(ConnectionContext context, Message message)
Not synchronized since the Journal has better throughput if you increase the number of concurrent writes that it is doing.void
JournalTopicMessageStore. addMessage(ConnectionContext context, Message message)
void
JournalMessageStore. addMessageReference(ConnectionContext context, MessageId messageId, long expirationTime, String messageRef)
void
JournalPersistenceAdapter. beginTransaction(ConnectionContext context)
void
JournalPersistenceAdapter. commitTransaction(ConnectionContext context)
void
JournalMessageStore. removeAllMessages(ConnectionContext context)
void
JournalMessageStore. removeMessage(ConnectionContext context, MessageAck ack)
void
JournalTopicMessageStore. replayAcknowledge(ConnectionContext context, String clientId, String subscritionName, MessageId messageId)
void
JournalMessageStore. replayAddMessage(ConnectionContext context, Message message)
void
JournalMessageStore. replayRemoveMessage(ConnectionContext context, MessageAck messageAck)
void
JournalPersistenceAdapter. rollbackTransaction(ConnectionContext context)
-
Uses of ConnectionContext in org.apache.activemq.store.kahadb
Methods in org.apache.activemq.store.kahadb with parameters of type ConnectionContext Modifier and Type Method Description void
KahaDBStore.KahaDBMessageStore. addMessage(ConnectionContext context, Message message)
void
TempKahaDBStore.KahaDBMessageStore. addMessage(ConnectionContext context, Message message)
ListenableFuture<Object>
KahaDBStore.KahaDBMessageStore. asyncAddQueueMessage(ConnectionContext context, Message message)
void
KahaDBPersistenceAdapter. beginTransaction(ConnectionContext context)
void
KahaDBStore. beginTransaction(ConnectionContext context)
void
MultiKahaDBPersistenceAdapter. beginTransaction(ConnectionContext context)
void
TempKahaDBStore. beginTransaction(ConnectionContext context)
void
KahaDBPersistenceAdapter. commitTransaction(ConnectionContext context)
void
KahaDBStore. commitTransaction(ConnectionContext context)
void
MultiKahaDBPersistenceAdapter. commitTransaction(ConnectionContext context)
void
TempKahaDBStore. commitTransaction(ConnectionContext context)
void
KahaDBStore.KahaDBMessageStore. removeAllMessages(ConnectionContext context)
void
TempKahaDBStore.KahaDBMessageStore. removeAllMessages(ConnectionContext context)
void
KahaDBStore.KahaDBMessageStore. removeAsyncMessage(ConnectionContext context, MessageAck ack)
void
KahaDBStore.KahaDBMessageStore. removeMessage(ConnectionContext context, MessageAck ack)
void
TempKahaDBStore.KahaDBMessageStore. removeMessage(ConnectionContext context, MessageAck ack)
void
KahaDBPersistenceAdapter. rollbackTransaction(ConnectionContext context)
void
KahaDBStore. rollbackTransaction(ConnectionContext context)
void
MultiKahaDBPersistenceAdapter. rollbackTransaction(ConnectionContext context)
void
TempKahaDBStore. rollbackTransaction(ConnectionContext context)
-
Uses of ConnectionContext in org.apache.activemq.store.memory
Methods in org.apache.activemq.store.memory with parameters of type ConnectionContext Modifier and Type Method Description void
MemoryTopicMessageStore. acknowledge(ConnectionContext context, String clientId, String subscriptionName, MessageId messageId, MessageAck ack)
void
MemoryMessageStore. addMessage(ConnectionContext context, Message message)
void
MemoryTopicMessageStore. addMessage(ConnectionContext context, Message message)
void
MemoryPersistenceAdapter. beginTransaction(ConnectionContext context)
void
MemoryPersistenceAdapter. commitTransaction(ConnectionContext context)
void
MemoryMessageStore. removeAllMessages(ConnectionContext context)
void
MemoryMessageStore. removeMessage(ConnectionContext context, MessageAck ack)
void
MemoryPersistenceAdapter. rollbackTransaction(ConnectionContext context)
void
MemoryTransactionStore.AddMessageCommand. run(ConnectionContext context)
void
MemoryTransactionStore.RemoveMessageCommand. run(ConnectionContext context)
-
Uses of ConnectionContext in org.apache.activemq.transaction
Constructors in org.apache.activemq.transaction with parameters of type ConnectionContext Constructor Description LocalTransaction(TransactionStore transactionStore, LocalTransactionId xid, ConnectionContext context)
-
Uses of ConnectionContext in org.apache.activemq.util
Methods in org.apache.activemq.util that return ConnectionContext Modifier and Type Method Description protected static ConnectionContext
BrokerSupport. createAdminConnectionContext(Broker broker)
Factory method to create the new administration connection context object.static ConnectionContext
BrokerSupport. getConnectionContext(Broker broker)
Returns the broker's administration connection context used for configuring the broker at startupConnectionContext
TransactionTemplate. getContext()
Methods in org.apache.activemq.util with parameters of type ConnectionContext Modifier and Type Method Description static void
BrokerSupport. doResend(ConnectionContext context, Message originalMessage, ActiveMQDestination deadLetterDestination, boolean copy)
static void
BrokerSupport. resend(ConnectionContext context, Message originalMessage, ActiveMQDestination deadLetterDestination)
static void
BrokerSupport. resendNoCopy(ConnectionContext context, Message originalMessage, ActiveMQDestination deadLetterDestination)
Constructors in org.apache.activemq.util with parameters of type ConnectionContext Constructor Description TransactionTemplate(PersistenceAdapter persistenceAdapter, ConnectionContext context)
-