Uses of Class
org.apache.activemq.broker.ConnectionContext

Packages that use ConnectionContext
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.ft Helper classes for implementing fault tolerance 
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 store 
org.apache.activemq.broker.region.policy The policies which can be associated with a particular destination or wildcard. 
org.apache.activemq.broker.util Some utility Broker Plugins 
org.apache.activemq.broker.view Broker Plugins for visualising the current system 
org.apache.activemq.plugin   
org.apache.activemq.security Plugable Security Adapter framework along with default implementations such as the JAAS implementation. 
org.apache.activemq.store The APIs which need to be implemented for persistent message stores for durable messaging 
org.apache.activemq.store.amq The default Store implementation for ActiveMQ 
org.apache.activemq.store.jdbc Message persistence implemented using JDBC 
org.apache.activemq.store.journal Message persistence using a high performance transaction log via the Journal interface. 
org.apache.activemq.store.kahadaptor kaha implementation of message persistence for the broker 
org.apache.activemq.store.kahadb   
org.apache.activemq.store.memory VM based implementation of message persistence 
org.apache.activemq.transaction   
org.apache.activemq.util Some utility classes 
 

Uses of ConnectionContext in org.apache.activemq.advisory
 

Methods in org.apache.activemq.advisory with parameters of type ConnectionContext
 void AdvisoryBroker.addConnection(ConnectionContext context, ConnectionInfo info)
           
 Subscription AdvisoryBroker.addConsumer(ConnectionContext context, ConsumerInfo info)
           
 Destination AdvisoryBroker.addDestination(ConnectionContext context, ActiveMQDestination destination)
           
 void AdvisoryBroker.addDestinationInfo(ConnectionContext context, DestinationInfo info)
           
 void AdvisoryBroker.addProducer(ConnectionContext context, ProducerInfo info)
           
 void AdvisoryBroker.fastProducer(ConnectionContext context, ProducerInfo producerInfo)
           
protected  void AdvisoryBroker.fireAdvisory(ConnectionContext context, ActiveMQTopic topic, Command command)
           
protected  void AdvisoryBroker.fireAdvisory(ConnectionContext context, ActiveMQTopic topic, Command command, ConsumerId targetConsumerId)
           
protected  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, MessageReference messageReference)
           
 void AdvisoryBroker.messageExpired(ConnectionContext context, MessageReference messageReference)
           
 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.slowConsumer(ConnectionContext context, Destination destination, Subscription subs)
           
 

Uses of ConnectionContext in org.apache.activemq.broker
 

Methods in org.apache.activemq.broker that return ConnectionContext
 ConnectionContext ConnectionContext.copy()
           
protected  ConnectionContext BrokerService.createAdminConnectionContext()
          Factory method to create the new administration connection context object.
 ConnectionContext Broker.getAdminConnectionContext()
           
 ConnectionContext EmptyBroker.getAdminConnectionContext()
           
 ConnectionContext MutableBrokerFilter.getAdminConnectionContext()
           
 ConnectionContext BrokerFilter.getAdminConnectionContext()
           
 ConnectionContext ErrorBroker.getAdminConnectionContext()
           
 ConnectionContext BrokerService.getAdminConnectionContext()
          Returns the broker's administration connection context used for configuring the broker at startup
 ConnectionContext ProducerBrokerExchange.getConnectionContext()
           
 ConnectionContext ConsumerBrokerExchange.getConnectionContext()
           
 ConnectionContext TransportConnectionState.getContext()
           
 

Methods in org.apache.activemq.broker with parameters of type ConnectionContext
 void Broker.addConnection(ConnectionContext context, ConnectionInfo info)
          A client is establishing a connection with the broker.
 void EmptyBroker.addConnection(ConnectionContext context, ConnectionInfo info)
           
 void MutableBrokerFilter.addConnection(ConnectionContext context, ConnectionInfo info)
           
 void BrokerFilter.addConnection(ConnectionContext context, ConnectionInfo info)
           
 void BrokerBroadcaster.addConnection(ConnectionContext context, ConnectionInfo info)
           
 void ErrorBroker.addConnection(ConnectionContext context, ConnectionInfo info)
           
 Subscription EmptyBroker.addConsumer(ConnectionContext context, ConsumerInfo info)
           
 Subscription MutableBrokerFilter.addConsumer(ConnectionContext context, ConsumerInfo info)
           
 Subscription BrokerFilter.addConsumer(ConnectionContext context, ConsumerInfo info)
           
 Subscription BrokerBroadcaster.addConsumer(ConnectionContext context, ConsumerInfo info)
           
 Subscription ErrorBroker.addConsumer(ConnectionContext context, ConsumerInfo info)
           
 Destination EmptyBroker.addDestination(ConnectionContext context, ActiveMQDestination destination)
           
 Destination MutableBrokerFilter.addDestination(ConnectionContext context, ActiveMQDestination destination)
           
 Destination BrokerFilter.addDestination(ConnectionContext context, ActiveMQDestination destination)
           
 Destination BrokerBroadcaster.addDestination(ConnectionContext context, ActiveMQDestination destination)
           
 Destination ErrorBroker.addDestination(ConnectionContext context, ActiveMQDestination destination)
           
 void Broker.addDestinationInfo(ConnectionContext context, DestinationInfo info)
          Add and process a DestinationInfo object
 void EmptyBroker.addDestinationInfo(ConnectionContext context, DestinationInfo info)
           
 void MutableBrokerFilter.addDestinationInfo(ConnectionContext context, DestinationInfo info)
           
 void BrokerFilter.addDestinationInfo(ConnectionContext context, DestinationInfo info)
           
 void ErrorBroker.addDestinationInfo(ConnectionContext context, DestinationInfo info)
           
 void Broker.addProducer(ConnectionContext context, ProducerInfo info)
          Adds a producer.
 void EmptyBroker.addProducer(ConnectionContext context, ProducerInfo info)
           
 void MutableBrokerFilter.addProducer(ConnectionContext context, ProducerInfo info)
           
 void BrokerFilter.addProducer(ConnectionContext context, ProducerInfo info)
           
 void BrokerBroadcaster.addProducer(ConnectionContext context, ProducerInfo info)
           
 void ErrorBroker.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 Broker.addSession(ConnectionContext context, SessionInfo info)
          Adds a session.
 void EmptyBroker.addSession(ConnectionContext context, SessionInfo info)
           
 void MutableBrokerFilter.addSession(ConnectionContext context, SessionInfo info)
           
 void BrokerFilter.addSession(ConnectionContext context, SessionInfo info)
           
 void BrokerBroadcaster.addSession(ConnectionContext context, SessionInfo info)
           
 void ErrorBroker.addSession(ConnectionContext context, SessionInfo info)
           
 void Broker.beginTransaction(ConnectionContext context, TransactionId xid)
          Starts a transaction.
 void EmptyBroker.beginTransaction(ConnectionContext context, TransactionId xid)
           
 void MutableBrokerFilter.beginTransaction(ConnectionContext context, TransactionId xid)
           
 void BrokerFilter.beginTransaction(ConnectionContext context, TransactionId xid)
           
 void TransactionBroker.beginTransaction(ConnectionContext context, TransactionId xid)
           
 void BrokerBroadcaster.beginTransaction(ConnectionContext context, TransactionId xid)
           
 void ErrorBroker.beginTransaction(ConnectionContext context, TransactionId xid)
           
 void Broker.commitTransaction(ConnectionContext context, TransactionId xid, boolean onePhase)
          Commits a transaction.
 void EmptyBroker.commitTransaction(ConnectionContext context, TransactionId xid, boolean onePhase)
           
 void MutableBrokerFilter.commitTransaction(ConnectionContext context, TransactionId xid, boolean onePhase)
           
 void BrokerFilter.commitTransaction(ConnectionContext context, TransactionId xid, boolean onePhase)
           
 void TransactionBroker.commitTransaction(ConnectionContext context, TransactionId xid, boolean onePhase)
           
 void BrokerBroadcaster.commitTransaction(ConnectionContext context, TransactionId xid, boolean onePhase)
           
 void ErrorBroker.commitTransaction(ConnectionContext context, TransactionId xid, boolean onePhase)
           
 void Broker.fastProducer(ConnectionContext context, ProducerInfo producerInfo)
          Called to notify a producer is too fast
 void EmptyBroker.fastProducer(ConnectionContext context, ProducerInfo producerInfo)
           
 void MutableBrokerFilter.fastProducer(ConnectionContext context, ProducerInfo producerInfo)
           
 void BrokerFilter.fastProducer(ConnectionContext context, ProducerInfo producerInfo)
           
 void ErrorBroker.fastProducer(ConnectionContext context, ProducerInfo producerInfo)
           
 void Broker.forgetTransaction(ConnectionContext context, TransactionId transactionId)
          Forgets a transaction.
 void EmptyBroker.forgetTransaction(ConnectionContext context, TransactionId transactionId)
           
 void MutableBrokerFilter.forgetTransaction(ConnectionContext context, TransactionId transactionId)
           
 void BrokerFilter.forgetTransaction(ConnectionContext context, TransactionId transactionId)
           
 void TransactionBroker.forgetTransaction(ConnectionContext context, TransactionId xid)
           
 void BrokerBroadcaster.forgetTransaction(ConnectionContext context, TransactionId transactionId)
           
 void ErrorBroker.forgetTransaction(ConnectionContext context, TransactionId transactionId)
           
 TransactionId[] Broker.getPreparedTransactions(ConnectionContext context)
          Gets a list of all the prepared xa transactions.
 TransactionId[] EmptyBroker.getPreparedTransactions(ConnectionContext context)
           
 TransactionId[] MutableBrokerFilter.getPreparedTransactions(ConnectionContext context)
           
 TransactionId[] BrokerFilter.getPreparedTransactions(ConnectionContext context)
           
 TransactionId[] TransactionBroker.getPreparedTransactions(ConnectionContext context)
           
 TransactionId[] ErrorBroker.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 limit
 void EmptyBroker.isFull(ConnectionContext context, Destination destination, Usage usage)
           
 void MutableBrokerFilter.isFull(ConnectionContext context, Destination destination, Usage usage)
           
 void BrokerFilter.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 consumed
 void EmptyBroker.messageConsumed(ConnectionContext context, MessageReference messageReference)
           
 void MutableBrokerFilter.messageConsumed(ConnectionContext context, MessageReference messageReference)
           
 void BrokerFilter.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 broker
 void EmptyBroker.messageDelivered(ConnectionContext context, MessageReference messageReference)
           
 void MutableBrokerFilter.messageDelivered(ConnectionContext context, MessageReference messageReference)
           
 void BrokerFilter.messageDelivered(ConnectionContext context, MessageReference messageReference)
           
 void ErrorBroker.messageDelivered(ConnectionContext context, MessageReference messageReference)
           
 void Broker.messageDiscarded(ConnectionContext context, MessageReference messageReference)
          Called when a message is discarded - e.g.
 void EmptyBroker.messageDiscarded(ConnectionContext context, MessageReference messageReference)
           
 void MutableBrokerFilter.messageDiscarded(ConnectionContext context, MessageReference messageReference)
           
 void BrokerFilter.messageDiscarded(ConnectionContext context, MessageReference messageReference)
           
 void ErrorBroker.messageDiscarded(ConnectionContext context, MessageReference messageReference)
           
 void Broker.messageExpired(ConnectionContext context, MessageReference messageReference)
          A Message has Expired
 void EmptyBroker.messageExpired(ConnectionContext context, MessageReference message)
           
 void MutableBrokerFilter.messageExpired(ConnectionContext context, MessageReference message)
           
 void BrokerFilter.messageExpired(ConnectionContext context, MessageReference message)
           
 void ErrorBroker.messageExpired(ConnectionContext context, MessageReference message)
           
 Response EmptyBroker.messagePull(ConnectionContext context, MessagePull pull)
           
 Response MutableBrokerFilter.messagePull(ConnectionContext context, MessagePull pull)
           
 Response BrokerFilter.messagePull(ConnectionContext context, MessagePull pull)
           
 Response ErrorBroker.messagePull(ConnectionContext context, MessagePull pull)
           
 int Broker.prepareTransaction(ConnectionContext context, TransactionId xid)
          Prepares a transaction.
 int EmptyBroker.prepareTransaction(ConnectionContext context, TransactionId xid)
           
 int MutableBrokerFilter.prepareTransaction(ConnectionContext context, TransactionId xid)
           
 int BrokerFilter.prepareTransaction(ConnectionContext context, TransactionId xid)
           
 int TransactionBroker.prepareTransaction(ConnectionContext context, TransactionId xid)
           
 int BrokerBroadcaster.prepareTransaction(ConnectionContext context, TransactionId xid)
           
 int ErrorBroker.prepareTransaction(ConnectionContext context, TransactionId xid)
           
 void Broker.removeConnection(ConnectionContext context, ConnectionInfo info, Throwable error)
          A client is disconnecting from the broker.
 void EmptyBroker.removeConnection(ConnectionContext context, ConnectionInfo info, Throwable error)
           
 void MutableBrokerFilter.removeConnection(ConnectionContext context, ConnectionInfo info, Throwable error)
           
 void BrokerFilter.removeConnection(ConnectionContext context, ConnectionInfo info, Throwable error)
           
 void TransactionBroker.removeConnection(ConnectionContext context, ConnectionInfo info, Throwable error)
           
 void BrokerBroadcaster.removeConnection(ConnectionContext context, ConnectionInfo info, Throwable error)
           
 void ErrorBroker.removeConnection(ConnectionContext context, ConnectionInfo info, Throwable error)
           
 void EmptyBroker.removeConsumer(ConnectionContext context, ConsumerInfo info)
           
 void MutableBrokerFilter.removeConsumer(ConnectionContext context, ConsumerInfo info)
           
 void BrokerFilter.removeConsumer(ConnectionContext context, ConsumerInfo info)
           
 void BrokerBroadcaster.removeConsumer(ConnectionContext context, ConsumerInfo info)
           
 void ErrorBroker.removeConsumer(ConnectionContext context, ConsumerInfo info)
           
 void EmptyBroker.removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
           
 void MutableBrokerFilter.removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
           
 void BrokerFilter.removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
           
 void BrokerBroadcaster.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 object
 void EmptyBroker.removeDestinationInfo(ConnectionContext context, DestinationInfo info)
           
 void MutableBrokerFilter.removeDestinationInfo(ConnectionContext context, DestinationInfo info)
           
 void BrokerFilter.removeDestinationInfo(ConnectionContext context, DestinationInfo info)
           
 void ErrorBroker.removeDestinationInfo(ConnectionContext context, DestinationInfo info)
           
 void Broker.removeProducer(ConnectionContext context, ProducerInfo info)
          Removes a producer.
 void EmptyBroker.removeProducer(ConnectionContext context, ProducerInfo info)
           
 void MutableBrokerFilter.removeProducer(ConnectionContext context, ProducerInfo info)
           
 void BrokerFilter.removeProducer(ConnectionContext context, ProducerInfo info)
           
 void BrokerBroadcaster.removeProducer(ConnectionContext context, ProducerInfo info)
           
 void ErrorBroker.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 Broker.removeSession(ConnectionContext context, SessionInfo info)
          Removes a session.
 void EmptyBroker.removeSession(ConnectionContext context, SessionInfo info)
           
 void MutableBrokerFilter.removeSession(ConnectionContext context, SessionInfo info)
           
 void BrokerFilter.removeSession(ConnectionContext context, SessionInfo info)
           
 void BrokerBroadcaster.removeSession(ConnectionContext context, SessionInfo info)
           
 void ErrorBroker.removeSession(ConnectionContext context, SessionInfo info)
           
 void EmptyBroker.removeSubscription(ConnectionContext context, RemoveSubscriptionInfo info)
           
 void MutableBrokerFilter.removeSubscription(ConnectionContext context, RemoveSubscriptionInfo info)
           
 void BrokerFilter.removeSubscription(ConnectionContext context, RemoveSubscriptionInfo info)
           
 void BrokerBroadcaster.removeSubscription(ConnectionContext context, RemoveSubscriptionInfo info)
           
 void ErrorBroker.removeSubscription(ConnectionContext context, RemoveSubscriptionInfo info)
           
 void Broker.rollbackTransaction(ConnectionContext context, TransactionId xid)
          Rollsback a transaction.
 void EmptyBroker.rollbackTransaction(ConnectionContext context, TransactionId xid)
           
 void MutableBrokerFilter.rollbackTransaction(ConnectionContext context, TransactionId xid)
           
 void BrokerFilter.rollbackTransaction(ConnectionContext context, TransactionId xid)
           
 void TransactionBroker.rollbackTransaction(ConnectionContext context, TransactionId xid)
           
 void BrokerBroadcaster.rollbackTransaction(ConnectionContext context, TransactionId xid)
           
 void ErrorBroker.rollbackTransaction(ConnectionContext context, TransactionId xid)
           
 void Broker.sendToDeadLetterQueue(ConnectionContext context, MessageReference messageReference)
          A message needs to go the a DLQ
 void EmptyBroker.sendToDeadLetterQueue(ConnectionContext context, MessageReference messageReference)
           
 void MutableBrokerFilter.sendToDeadLetterQueue(ConnectionContext context, MessageReference messageReference)
           
 void BrokerFilter.sendToDeadLetterQueue(ConnectionContext context, MessageReference messageReference)
           
 void ErrorBroker.sendToDeadLetterQueue(ConnectionContext context, MessageReference messageReference)
           
 void Broker.setAdminConnectionContext(ConnectionContext adminConnectionContext)
          Sets the default administration connection context used when configuring the broker on startup or via JMX
 void EmptyBroker.setAdminConnectionContext(ConnectionContext adminConnectionContext)
           
 void MutableBrokerFilter.setAdminConnectionContext(ConnectionContext adminConnectionContext)
           
 void BrokerFilter.setAdminConnectionContext(ConnectionContext adminConnectionContext)
           
 void ErrorBroker.setAdminConnectionContext(ConnectionContext adminConnectionContext)
           
 void ProducerBrokerExchange.setConnectionContext(ConnectionContext connectionContext)
           
 void ConsumerBrokerExchange.setConnectionContext(ConnectionContext connectionContext)
           
 void TransportConnectionState.setContext(ConnectionContext context)
           
 void Broker.slowConsumer(ConnectionContext context, Destination destination, Subscription subs)
          Called when there is a slow consumer
 void EmptyBroker.slowConsumer(ConnectionContext context, Destination destination, Subscription subs)
           
 void MutableBrokerFilter.slowConsumer(ConnectionContext context, Destination dest, Subscription subs)
           
 void BrokerFilter.slowConsumer(ConnectionContext context, Destination destination, Subscription subs)
           
 void ErrorBroker.slowConsumer(ConnectionContext context, Destination destination, Subscription subs)
           
 

Uses of ConnectionContext in org.apache.activemq.broker.cluster
 

Methods in org.apache.activemq.broker.cluster with parameters of type ConnectionContext
 Subscription ConnectionSplitBroker.addConsumer(ConnectionContext context, ConsumerInfo info)
           
 void ConnectionSplitBroker.removeConsumer(ConnectionContext context, ConsumerInfo info)
           
 

Uses of ConnectionContext in org.apache.activemq.broker.ft
 

Methods in org.apache.activemq.broker.ft with parameters of type ConnectionContext
 void MasterBroker.addConnection(ConnectionContext context, ConnectionInfo info)
          A client is establishing a connection with the broker.
 Subscription MasterBroker.addConsumer(ConnectionContext context, ConsumerInfo info)
          add a consumer
 void MasterBroker.addDestinationInfo(ConnectionContext context, DestinationInfo info)
           
 void MasterBroker.addProducer(ConnectionContext context, ProducerInfo info)
          Adds a producer.
 void MasterBroker.addSession(ConnectionContext context, SessionInfo info)
          Adds a session.
 void MasterBroker.beginTransaction(ConnectionContext context, TransactionId xid)
          begin a transaction
 void MasterBroker.commitTransaction(ConnectionContext context, TransactionId xid, boolean onePhase)
          Commits a transaction.
 void MasterBroker.forgetTransaction(ConnectionContext context, TransactionId xid)
          Forgets a transaction.
 int MasterBroker.prepareTransaction(ConnectionContext context, TransactionId xid)
          Prepares a transaction.
 void MasterBroker.removeConnection(ConnectionContext context, ConnectionInfo info, Throwable error)
          A client is disconnecting from the broker.
 void MasterBroker.removeConsumer(ConnectionContext context, ConsumerInfo info)
           
 void MasterBroker.removeDestinationInfo(ConnectionContext context, DestinationInfo info)
           
 void MasterBroker.removeProducer(ConnectionContext context, ProducerInfo info)
          Removes a producer.
 void MasterBroker.removeSession(ConnectionContext context, SessionInfo info)
          Removes a session.
 void MasterBroker.removeSubscription(ConnectionContext context, RemoveSubscriptionInfo info)
          remove a subscription
 void MasterBroker.rollbackTransaction(ConnectionContext context, TransactionId xid)
          Rollsback a transaction.
 

Uses of ConnectionContext in org.apache.activemq.broker.jmx
 

Methods in org.apache.activemq.broker.jmx that return ConnectionContext
protected static ConnectionContext BrokerView.createAdminConnectionContext(Broker broker)
          Factory method to create the new administration connection context object.
static ConnectionContext BrokerView.getConnectionContext(Broker broker)
          Returns the broker's administration connection context used for configuring the broker at startup
 

Methods in org.apache.activemq.broker.jmx with parameters of type ConnectionContext
protected  Destination ManagedTempQueueRegion.createDestination(ConnectionContext context, ActiveMQDestination destination)
           
protected  Destination ManagedTopicRegion.createDestination(ConnectionContext context, ActiveMQDestination destination)
           
protected  Destination ManagedQueueRegion.createDestination(ConnectionContext context, ActiveMQDestination destination)
           
protected  Destination ManagedTempTopicRegion.createDestination(ConnectionContext context, ActiveMQDestination destination)
           
protected  Subscription ManagedTempQueueRegion.createSubscription(ConnectionContext context, ConsumerInfo info)
           
protected  Subscription ManagedTopicRegion.createSubscription(ConnectionContext context, ConsumerInfo info)
           
protected  Subscription ManagedQueueRegion.createSubscription(ConnectionContext context, ConsumerInfo info)
           
protected  Subscription ManagedTempTopicRegion.createSubscription(ConnectionContext context, ConsumerInfo info)
           
 ObjectName ManagedRegionBroker.registerSubscription(ConnectionContext context, Subscription sub)
           
 void ManagedTempQueueRegion.removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
           
 void ManagedTopicRegion.removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
           
 void ManagedQueueRegion.removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
           
 void ManagedTempTopicRegion.removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
           
 

Uses of ConnectionContext in org.apache.activemq.broker.region
 

Fields in org.apache.activemq.broker.region declared as ConnectionContext
protected  ConnectionContext AbstractSubscription.context
           
 

Methods in org.apache.activemq.broker.region that return ConnectionContext
protected  ConnectionContext Queue.createConnectionContext()
           
 ConnectionContext RegionBroker.getAdminConnectionContext()
           
 ConnectionContext Subscription.getContext()
           
 ConnectionContext AbstractSubscription.getContext()
           
 

Methods in org.apache.activemq.broker.region with parameters of type ConnectionContext
 void Subscription.acknowledge(ConnectionContext context, MessageAck ack)
          Used when client acknowledge receipt of dispatched message.
 void PrefetchSubscription.acknowledge(ConnectionContext context, MessageAck ack)
           
 void TopicSubscription.acknowledge(ConnectionContext context, MessageAck ack)
           
protected abstract  void PrefetchSubscription.acknowledge(ConnectionContext context, MessageAck ack, MessageReference node)
          Used during acknowledgment to remove the message.
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.
protected  void DurableTopicSubscription.acknowledge(ConnectionContext context, 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.
 void Destination.acknowledge(ConnectionContext context, Subscription sub, MessageAck ack, MessageReference node)
           
 void Topic.acknowledge(ConnectionContext context, Subscription sub, MessageAck ack, MessageReference node)
           
 void DestinationFilter.acknowledge(ConnectionContext context, Subscription sub, MessageAck ack, MessageReference node)
           
 void Queue.acknowledge(ConnectionContext context, Subscription sub, MessageAck ack, MessageReference node)
           
 void Topic.activate(ConnectionContext context, DurableTopicSubscription subscription)
           
 void DurableTopicSubscription.activate(SystemUsage memoryManager, ConnectionContext context, ConsumerInfo info)
           
 void Subscription.add(ConnectionContext context, Destination destination)
          The subscription will be receiving messages from the destination.
 void AbstractSubscription.add(ConnectionContext context, Destination destination)
           
 void PrefetchSubscription.add(ConnectionContext context, Destination destination)
           
 void DurableTopicSubscription.add(ConnectionContext context, Destination destination)
           
 void RegionBroker.addConnection(ConnectionContext context, ConnectionInfo info)
           
 Subscription Region.addConsumer(ConnectionContext context, ConsumerInfo info)
          Adds a consumer.
 Subscription AbstractRegion.addConsumer(ConnectionContext context, ConsumerInfo info)
           
 Subscription TopicRegion.addConsumer(ConnectionContext context, ConsumerInfo info)
           
 Subscription RegionBroker.addConsumer(ConnectionContext context, ConsumerInfo info)
           
 Destination Region.addDestination(ConnectionContext context, ActiveMQDestination destination)
          Used to create a destination.
 Destination AbstractRegion.addDestination(ConnectionContext context, ActiveMQDestination destination)
           
 Destination RegionBroker.addDestination(ConnectionContext context, ActiveMQDestination destination)
           
 void RegionBroker.addDestinationInfo(ConnectionContext context, DestinationInfo info)
           
 void Destination.addProducer(ConnectionContext context, ProducerInfo info)
           
 void Region.addProducer(ConnectionContext context, ProducerInfo info)
          Adds a Producer.
 void BaseDestination.addProducer(ConnectionContext context, ProducerInfo info)
           
 void AbstractRegion.addProducer(ConnectionContext context, ProducerInfo info)
           
 void DestinationFilter.addProducer(ConnectionContext context, ProducerInfo info)
           
 void RegionBroker.addProducer(ConnectionContext context, ProducerInfo info)
           
 boolean SubscriptionRecovery.addRecoveredMessage(ConnectionContext context, MessageReference message)
          Add a message to the SubscriptionRecovery
 boolean AbstractSubscription.addRecoveredMessage(ConnectionContext context, MessageReference message)
           
 void Destination.addSubscription(ConnectionContext context, Subscription sub)
           
 void Topic.addSubscription(ConnectionContext context, Subscription sub)
           
 void DestinationFilter.addSubscription(ConnectionContext context, Subscription sub)
           
 void TempTopic.addSubscription(ConnectionContext context, Subscription sub)
           
 void Queue.addSubscription(ConnectionContext context, Subscription sub)
           
 void TempQueue.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 messages
 int Queue.copyMatchingMessagesTo(ConnectionContext context, String selector, ActiveMQDestination dest)
          Copies the messages matching the given selector
 int Queue.copyMatchingMessagesTo(ConnectionContext context, String selector, ActiveMQDestination dest, int maximumMessages)
          Copies the messages matching the given selector up to the maximum number of matched messages
 boolean Queue.copyMessageTo(ConnectionContext context, String messageId, ActiveMQDestination dest)
          Copies the message matching the given messageId
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 TopicRegion.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)
           
 void Topic.deactivate(ConnectionContext context, DurableTopicSubscription sub)
           
 void Topic.deleteSubscription(ConnectionContext context, SubscriptionKey key)
           
protected  void Topic.dispatch(ConnectionContext context, Message message)
           
 void Destination.dispose(ConnectionContext context)
           
 void BaseDestination.dispose(ConnectionContext context)
           
 void DestinationFilter.dispose(ConnectionContext context)
           
 void TempQueue.dispose(ConnectionContext context)
           
protected  void AbstractRegion.dispose(ConnectionContext context, Destination dest)
           
protected  void AbstractTempRegion.dispose(ConnectionContext context, Destination dest)
           
protected abstract  Destination AbstractTempRegion.doCreateDestination(ConnectionContext context, ActiveMQDestination destination)
           
protected  Destination TempQueueRegion.doCreateDestination(ConnectionContext context, ActiveMQDestination destination)
           
protected  Destination TempTopicRegion.doCreateDestination(ConnectionContext context, ActiveMQDestination destination)
           
 boolean MessageReferenceFilter.evaluate(ConnectionContext context, MessageReference messageReference)
           
 void Destination.fastProducer(ConnectionContext context, ProducerInfo producerInfo)
          Called to notify a producer is too fast
 void BaseDestination.fastProducer(ConnectionContext context, ProducerInfo producerInfo)
          Called to notify a producer is too fast
 void DestinationFilter.fastProducer(ConnectionContext context, ProducerInfo producerInfo)
           
 void RegionBroker.forgetTransaction(ConnectionContext context, TransactionId transactionId)
           
 TransactionId[] RegionBroker.getPreparedTransactions(ConnectionContext context)
           
 void Destination.isFull(ConnectionContext context, Usage usage)
          Called when a Usage reaches a limit
 void BaseDestination.isFull(ConnectionContext context, Usage usage)
          Called when a Usage reaches a limit
 void DestinationFilter.isFull(ConnectionContext context, Usage usage)
           
protected  Destination AbstractRegion.lookup(ConnectionContext context, ActiveMQDestination destination)
           
 void Destination.messageConsumed(ConnectionContext context, MessageReference messageReference)
          called when message is consumed
 void BaseDestination.messageConsumed(ConnectionContext context, MessageReference messageReference)
          called when message is consumed
 void DestinationFilter.messageConsumed(ConnectionContext context, MessageReference messageReference)
           
 void Destination.messageDelivered(ConnectionContext context, MessageReference messageReference)
          Called when message is delivered to the broker
 void BaseDestination.messageDelivered(ConnectionContext context, MessageReference messageReference)
          Called when message is delivered to the broker
 void DestinationFilter.messageDelivered(ConnectionContext context, MessageReference messageReference)
           
 void Destination.messageDiscarded(ConnectionContext context, MessageReference messageReference)
          Called when a message is discarded - e.g.
 void BaseDestination.messageDiscarded(ConnectionContext context, MessageReference messageReference)
          Called when a message is discarded - e.g.
 void DestinationFilter.messageDiscarded(ConnectionContext context, MessageReference messageReference)
           
 void RegionBroker.messageExpired(ConnectionContext context, MessageReference node)
           
 void Queue.messageExpired(ConnectionContext context, MessageReference reference)
           
 void DestinationFilter.messageExpired(ConnectionContext context, PrefetchSubscription prefetchSubscription, MessageReference node)
           
 void Destination.messageExpired(ConnectionContext context, Subscription subs, MessageReference node)
          Inform the Destination a message has expired
 void Topic.messageExpired(ConnectionContext context, Subscription subs, MessageReference reference)
           
 void DestinationFilter.messageExpired(ConnectionContext context, Subscription subs, MessageReference node)
           
 void Queue.messageExpired(ConnectionContext context, Subscription subs, MessageReference reference)
           
 Response Region.messagePull(ConnectionContext context, MessagePull pull)
          Allows a consumer to pull a message from a queue
 Response AbstractRegion.messagePull(ConnectionContext context, MessagePull pull)
           
 Response RegionBroker.messagePull(ConnectionContext context, MessagePull pull)
           
 int Queue.moveMatchingMessagesTo(ConnectionContext context, MessageReferenceFilter filter, ActiveMQDestination dest, int maximumMessages)
          Moves the messages matching the given filter up to the maximum number of matched messages
 int Queue.moveMatchingMessagesTo(ConnectionContext context, String selector, ActiveMQDestination dest)
          Moves the messages matching the given selector
 int Queue.moveMatchingMessagesTo(ConnectionContext context, String selector, ActiveMQDestination dest, int maximumMessages)
          Moves the messages matching the given selector up to the maximum number of matched messages
 boolean Queue.moveMessageTo(ConnectionContext context, Message m, ActiveMQDestination dest)
          Move a message
 boolean Queue.moveMessageTo(ConnectionContext context, String messageId, ActiveMQDestination dest)
          Moves the message matching the given messageId
protected  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 Subscription.pullMessage(ConnectionContext context, MessagePull pull)
          Allows a consumer to pull a message on demand
 Response PrefetchSubscription.pullMessage(ConnectionContext context, MessagePull pull)
          Allows a message to be pulled on demand by a client
 Response TopicSubscription.pullMessage(ConnectionContext context, MessagePull pull)
           
protected  void Topic.recoverRetroactiveMessages(ConnectionContext context, Subscription subscription)
           
 List<MessageReference> Subscription.remove(ConnectionContext context, Destination destination)
          The subscription will be no longer be receiving messages from the destination.
 List<MessageReference> AbstractSubscription.remove(ConnectionContext context, Destination destination)
           
 List<MessageReference> PrefetchSubscription.remove(ConnectionContext context, Destination destination)
           
 void RegionBroker.removeConnection(ConnectionContext context, ConnectionInfo info, Throwable error)
           
 void Region.removeConsumer(ConnectionContext context, ConsumerInfo info)
          Removes a consumer.
 void AbstractRegion.removeConsumer(ConnectionContext context, ConsumerInfo info)
           
 void TopicRegion.removeConsumer(ConnectionContext context, ConsumerInfo info)
           
 void RegionBroker.removeConsumer(ConnectionContext context, ConsumerInfo info)
           
 void Region.removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
          Used to destroy a destination.
 void AbstractRegion.removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
           
 void TempQueueRegion.removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
           
 void RegionBroker.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 Destination.removeProducer(ConnectionContext context, ProducerInfo info)
           
 void Region.removeProducer(ConnectionContext context, ProducerInfo info)
          Removes a Producer.
 void BaseDestination.removeProducer(ConnectionContext context, ProducerInfo info)
           
 void AbstractRegion.removeProducer(ConnectionContext context, ProducerInfo info)
          Removes a Producer.
 void DestinationFilter.removeProducer(ConnectionContext context, ProducerInfo info)
           
 void RegionBroker.removeProducer(ConnectionContext context, ProducerInfo info)
           
 void Region.removeSubscription(ConnectionContext context, RemoveSubscriptionInfo info)
          Deletes a durable subscription.
 void AbstractRegion.removeSubscription(ConnectionContext context, RemoveSubscriptionInfo info)
           
 void TopicRegion.removeSubscription(ConnectionContext context, RemoveSubscriptionInfo info)
           
 void RegionBroker.removeSubscription(ConnectionContext context, RemoveSubscriptionInfo info)
           
 void Destination.removeSubscription(ConnectionContext context, Subscription sub, long lastDeliveredSequenceId)
           
 void Topic.removeSubscription(ConnectionContext context, Subscription sub, long lastDeliveredSequenceId)
           
 void DestinationFilter.removeSubscription(ConnectionContext context, Subscription sub, long lastDeliveredSequenceId)
           
 void Queue.removeSubscription(ConnectionContext context, Subscription sub, long lastDeiveredSequenceId)
           
 void RegionBroker.rollbackTransaction(ConnectionContext context, TransactionId xid)
           
 void RegionBroker.sendToDeadLetterQueue(ConnectionContext context, MessageReference node)
           
protected  void PrefetchSubscription.sendToDLQ(ConnectionContext context, MessageReference node)
           
 void RegionBroker.setAdminConnectionContext(ConnectionContext adminConnectionContext)
           
 void Destination.slowConsumer(ConnectionContext context, Subscription subs)
          Called when there is a slow consumer
 void BaseDestination.slowConsumer(ConnectionContext context, Subscription subs)
          Called when there is a slow consumer
 void DestinationFilter.slowConsumer(ConnectionContext context, Subscription subs)
           
 

Constructors in org.apache.activemq.broker.region with parameters of type ConnectionContext
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
 void PendingMessageCursor.add(ConnectionContext context, Destination destination)
          Add a destination
 void AbstractPendingMessageCursor.add(ConnectionContext context, Destination destination)
           
 void StoreDurableSubscriberCursor.add(ConnectionContext context, Destination destination)
          Add a destination
 List<MessageReference> PendingMessageCursor.remove(ConnectionContext context, Destination destination)
          remove a destination
 List<MessageReference> AbstractPendingMessageCursor.remove(ConnectionContext context, Destination destination)
           
 List<MessageReference> StoreDurableSubscriberCursor.remove(ConnectionContext context, Destination destination)
          remove a destination
 List<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
 boolean SubscriptionRecoveryPolicy.add(ConnectionContext context, MessageReference message)
          A message was sent to the destination.
 boolean FixedCountSubscriptionRecoveryPolicy.add(ConnectionContext context, MessageReference node)
           
 boolean LastImageSubscriptionRecoveryPolicy.add(ConnectionContext context, MessageReference node)
           
 boolean TimedSubscriptionRecoveryPolicy.add(ConnectionContext context, MessageReference message)
           
 boolean FixedSizedSubscriptionRecoveryPolicy.add(ConnectionContext context, MessageReference message)
           
 boolean NoSubscriptionRecoveryPolicy.add(ConnectionContext context, MessageReference node)
           
 boolean QueryBasedSubscriptionRecoveryPolicy.add(ConnectionContext context, MessageReference message)
           
protected  void QueryBasedSubscriptionRecoveryPolicy.dispatchInitialMessage(Message message, Destination regionDestination, ConnectionContext context, SubscriptionRecovery sub)
           
 void SubscriptionRecoveryPolicy.recover(ConnectionContext context, Topic topic, SubscriptionRecovery sub)
          Let a subscription recover message held by the policy.
 void FixedCountSubscriptionRecoveryPolicy.recover(ConnectionContext context, Topic topic, SubscriptionRecovery sub)
           
 void LastImageSubscriptionRecoveryPolicy.recover(ConnectionContext context, Topic topic, SubscriptionRecovery sub)
           
 void TimedSubscriptionRecoveryPolicy.recover(ConnectionContext context, Topic topic, SubscriptionRecovery sub)
           
 void FixedSizedSubscriptionRecoveryPolicy.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)
           
 

Uses of ConnectionContext in org.apache.activemq.broker.util
 

Methods in org.apache.activemq.broker.util with parameters of type ConnectionContext
 void UDPTraceBrokerPlugin.addConnection(ConnectionContext context, ConnectionInfo info)
           
 void LoggingBrokerPlugin.addConnection(ConnectionContext context, ConnectionInfo info)
           
 Subscription UDPTraceBrokerPlugin.addConsumer(ConnectionContext context, ConsumerInfo info)
           
 Subscription LoggingBrokerPlugin.addConsumer(ConnectionContext context, ConsumerInfo info)
           
 Destination LoggingBrokerPlugin.addDestination(ConnectionContext context, ActiveMQDestination destination)
           
 void UDPTraceBrokerPlugin.addDestinationInfo(ConnectionContext context, DestinationInfo info)
           
 void LoggingBrokerPlugin.addDestinationInfo(ConnectionContext context, DestinationInfo info)
           
 void UDPTraceBrokerPlugin.addProducer(ConnectionContext context, ProducerInfo info)
           
 void LoggingBrokerPlugin.addProducer(ConnectionContext context, ProducerInfo info)
           
 void UDPTraceBrokerPlugin.addSession(ConnectionContext context, SessionInfo info)
           
 void LoggingBrokerPlugin.addSession(ConnectionContext context, SessionInfo info)
           
 void UDPTraceBrokerPlugin.beginTransaction(ConnectionContext context, TransactionId xid)
           
 void LoggingBrokerPlugin.beginTransaction(ConnectionContext context, TransactionId xid)
           
 void UDPTraceBrokerPlugin.commitTransaction(ConnectionContext context, TransactionId xid, boolean onePhase)
           
 void LoggingBrokerPlugin.commitTransaction(ConnectionContext context, TransactionId xid, boolean onePhase)
           
 void LoggingBrokerPlugin.fastProducer(ConnectionContext context, ProducerInfo producerInfo)
           
 void UDPTraceBrokerPlugin.forgetTransaction(ConnectionContext context, TransactionId xid)
           
 void LoggingBrokerPlugin.forgetTransaction(ConnectionContext context, TransactionId transactionId)
           
 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, MessageReference messageReference)
           
 void LoggingBrokerPlugin.messageExpired(ConnectionContext context, MessageReference message)
           
 Response UDPTraceBrokerPlugin.messagePull(ConnectionContext context, MessagePull pull)
           
 Response LoggingBrokerPlugin.messagePull(ConnectionContext context, MessagePull pull)
           
 int UDPTraceBrokerPlugin.prepareTransaction(ConnectionContext context, TransactionId xid)
           
 int LoggingBrokerPlugin.prepareTransaction(ConnectionContext context, TransactionId xid)
           
 void UDPTraceBrokerPlugin.removeConnection(ConnectionContext context, ConnectionInfo info, Throwable error)
           
 void LoggingBrokerPlugin.removeConnection(ConnectionContext context, ConnectionInfo info, Throwable error)
           
 void UDPTraceBrokerPlugin.removeConsumer(ConnectionContext context, ConsumerInfo info)
           
 void LoggingBrokerPlugin.removeConsumer(ConnectionContext context, ConsumerInfo info)
           
 void UDPTraceBrokerPlugin.removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
           
 void LoggingBrokerPlugin.removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
           
 void UDPTraceBrokerPlugin.removeDestinationInfo(ConnectionContext context, DestinationInfo info)
           
 void LoggingBrokerPlugin.removeDestinationInfo(ConnectionContext context, DestinationInfo info)
           
 void UDPTraceBrokerPlugin.removeProducer(ConnectionContext context, ProducerInfo info)
           
 void LoggingBrokerPlugin.removeProducer(ConnectionContext context, ProducerInfo info)
           
 void UDPTraceBrokerPlugin.removeSession(ConnectionContext context, SessionInfo info)
           
 void LoggingBrokerPlugin.removeSession(ConnectionContext context, SessionInfo info)
           
 void UDPTraceBrokerPlugin.removeSubscription(ConnectionContext context, RemoveSubscriptionInfo info)
           
 void LoggingBrokerPlugin.removeSubscription(ConnectionContext context, RemoveSubscriptionInfo info)
           
 void UDPTraceBrokerPlugin.rollbackTransaction(ConnectionContext context, TransactionId xid)
           
 void LoggingBrokerPlugin.rollbackTransaction(ConnectionContext context, TransactionId xid)
           
 void LoggingBrokerPlugin.sendToDeadLetterQueue(ConnectionContext context, MessageReference messageReference)
           
 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
 Subscription ConnectionDotFileInterceptor.addConsumer(ConnectionContext context, ConsumerInfo info)
           
 Destination DestinationDotFileInterceptor.addDestination(ConnectionContext context, ActiveMQDestination destination)
           
 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.plugin
 

Methods in org.apache.activemq.plugin with parameters of type ConnectionContext
protected  void StatisticsBroker.sendStats(ConnectionContext context, ActiveMQMapMessage msg, ActiveMQDestination replyTo)
           
 void DiscardingDLQBroker.sendToDeadLetterQueue(ConnectionContext ctx, MessageReference msgRef)
           
 

Uses of ConnectionContext in org.apache.activemq.security
 

Methods in org.apache.activemq.security with parameters of type ConnectionContext
 void JaasAuthenticationBroker.addConnection(ConnectionContext context, ConnectionInfo info)
           
 void JaasCertificateAuthenticationBroker.addConnection(ConnectionContext context, ConnectionInfo info)
          Overridden to allow for authentication based on client certificates.
 void SimpleAuthenticationBroker.addConnection(ConnectionContext context, ConnectionInfo info)
           
 Subscription AuthorizationBroker.addConsumer(ConnectionContext context, ConsumerInfo info)
           
 Destination AuthorizationBroker.addDestination(ConnectionContext context, ActiveMQDestination destination)
           
 void AuthorizationBroker.addDestinationInfo(ConnectionContext context, DestinationInfo info)
           
 void AuthorizationBroker.addProducer(ConnectionContext context, ProducerInfo info)
           
 boolean MessageAuthorizationPolicy.isAllowedToConsume(ConnectionContext context, Message message)
          Returns true if the given message is able to be dispatched to the connection performing any user
 void JaasAuthenticationBroker.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 SimpleAuthenticationBroker.removeConnection(ConnectionContext context, ConnectionInfo info, Throwable error)
           
 void AuthorizationBroker.removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
           
 

Uses of ConnectionContext in org.apache.activemq.store
 

Methods in org.apache.activemq.store with parameters of type ConnectionContext
 void TopicMessageStore.acknowledge(ConnectionContext context, String clientId, String subscriptionName, MessageId messageId)
          Stores the last acknowledged messgeID for the given subscription so that we can recover and commence dispatching messages from the last checkpoint
 void ProxyTopicMessageStore.acknowledge(ConnectionContext context, String clientId, String subscriptionName, MessageId messageId)
           
 boolean 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 MessageStore.addMessage(ConnectionContext context, Message message)
          Adds a message to the message store
 void ProxyMessageStore.addMessage(ConnectionContext context, Message message)
           
 void ProxyTopicMessageStore.addMessage(ConnectionContext context, Message message)
           
 boolean ReferenceStore.addMessageReference(ConnectionContext context, MessageId messageId, ReferenceStore.ReferenceData data)
          Adds a message reference to the message store
 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 transaction
 void MessageStore.dispose(ConnectionContext context)
           
 void AbstractMessageStore.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 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 transaction
 

Uses of ConnectionContext in org.apache.activemq.store.amq
 

Methods in org.apache.activemq.store.amq with parameters of type ConnectionContext
protected  void AMQTopicMessageStore.acknowledge(ConnectionContext context, MessageId messageId, Location location, String clientId, String subscriptionName)
           
 void AMQTopicMessageStore.acknowledge(ConnectionContext context, String clientId, String subscriptionName, MessageId messageId)
           
 void AMQMessageStore.addMessage(ConnectionContext context, Message message)
          Not synchronize since the Journal has better throughput if you increase the number of concurrent writes that it is doing.
 void AMQMessageStore.addMessageReference(ConnectionContext context, MessageId messageId, long expirationTime, String messageRef)
           
 void AMQPersistenceAdapter.beginTransaction(ConnectionContext context)
           
 void AMQPersistenceAdapter.commitTransaction(ConnectionContext context)
           
 void AMQMessageStore.dispose(ConnectionContext context)
           
 void AMQMessageStore.removeAllMessages(ConnectionContext context)
           
 void AMQMessageStore.removeMessage(ConnectionContext context, MessageAck ack)
           
 boolean AMQTxOperation.replay(AMQPersistenceAdapter adapter, ConnectionContext context)
           
 boolean AMQTopicMessageStore.replayAcknowledge(ConnectionContext context, String clientId, String subscritionName, MessageId messageId)
           
 boolean AMQMessageStore.replayAddMessage(ConnectionContext context, Message message, Location location)
           
 boolean AMQMessageStore.replayRemoveMessage(ConnectionContext context, MessageAck messageAck)
           
 void AMQPersistenceAdapter.rollbackTransaction(ConnectionContext context)
           
 

Uses of ConnectionContext in org.apache.activemq.store.jdbc
 

Methods in org.apache.activemq.store.jdbc with parameters of type ConnectionContext
 void JDBCTopicMessageStore.acknowledge(ConnectionContext context, String clientId, String subscriptionName, MessageId messageId)
           
 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.commitTransaction(ConnectionContext context)
           
 TransactionContext JDBCPersistenceAdapter.getTransactionContext(ConnectionContext context)
           
 void JDBCMessageStore.removeAllMessages(ConnectionContext context)
           
 void JDBCMessageStore.removeMessage(ConnectionContext context, MessageAck ack)
           
 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
 void JournalTopicMessageStore.acknowledge(ConnectionContext context, String clientId, String subscriptionName, MessageId messageId)
           
 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.kahadaptor
 

Methods in org.apache.activemq.store.kahadaptor with parameters of type ConnectionContext
 void KahaTopicMessageStore.acknowledge(ConnectionContext context, String clientId, String subscriptionName, MessageId messageId)
           
 void KahaTopicReferenceStore.acknowledge(ConnectionContext context, String clientId, String subscriptionName, MessageId messageId)
           
 boolean KahaTopicReferenceStore.acknowledgeReference(ConnectionContext context, String clientId, String subscriptionName, MessageId messageId)
           
 void KahaReferenceStore.addMessage(ConnectionContext context, Message message)
           
 void KahaMessageStore.addMessage(ConnectionContext context, Message message)
           
 void KahaTopicMessageStore.addMessage(ConnectionContext context, Message message)
           
 void KahaTopicReferenceStore.addMessage(ConnectionContext context, Message message)
           
 boolean KahaReferenceStore.addMessageReference(ConnectionContext context, MessageId messageId, ReferenceStore.ReferenceData data)
           
 boolean KahaTopicReferenceStore.addMessageReference(ConnectionContext context, MessageId messageId, ReferenceStore.ReferenceData data)
           
 void KahaPersistenceAdapter.beginTransaction(ConnectionContext context)
           
 void KahaPersistenceAdapter.commitTransaction(ConnectionContext context)
           
 void KahaReferenceStoreAdapter.commitTransaction(ConnectionContext context)
           
 void KahaReferenceStore.dispose(ConnectionContext context)
           
 void KahaTopicReferenceStore.dispose(ConnectionContext context)
           
 void KahaReferenceStore.removeAllMessages(ConnectionContext context)
           
 void KahaMessageStore.removeAllMessages(ConnectionContext context)
           
 void KahaTopicMessageStore.removeAllMessages(ConnectionContext context)
           
 void KahaTopicReferenceStore.removeAllMessages(ConnectionContext context)
           
 void KahaReferenceStore.removeMessage(ConnectionContext context, MessageAck ack)
           
 void KahaMessageStore.removeMessage(ConnectionContext context, MessageAck ack)
           
 void KahaPersistenceAdapter.rollbackTransaction(ConnectionContext context)
           
 

Uses of ConnectionContext in org.apache.activemq.store.kahadb
 

Methods in org.apache.activemq.store.kahadb with parameters of type ConnectionContext
 void KahaDBStore.KahaDBMessageStore.addMessage(ConnectionContext context, Message message)
           
 void TempKahaDBStore.KahaDBMessageStore.addMessage(ConnectionContext context, Message message)
           
 void KahaDBPersistenceAdapter.beginTransaction(ConnectionContext context)
           
 void KahaDBStore.beginTransaction(ConnectionContext context)
           
 void TempKahaDBStore.beginTransaction(ConnectionContext context)
           
 void KahaDBPersistenceAdapter.commitTransaction(ConnectionContext context)
           
 void KahaDBStore.commitTransaction(ConnectionContext context)
           
 void TempKahaDBStore.commitTransaction(ConnectionContext context)
           
 void KahaDBStore.KahaDBMessageStore.removeAllMessages(ConnectionContext context)
           
 void TempKahaDBStore.KahaDBMessageStore.removeAllMessages(ConnectionContext context)
           
 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 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
 void MemoryTopicMessageStore.acknowledge(ConnectionContext context, String clientId, String subscriptionName, MessageId messageId)
           
 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
LocalTransaction(TransactionStore transactionStore, LocalTransactionId xid, ConnectionContext context)
           
 

Uses of ConnectionContext in org.apache.activemq.util
 

Methods in org.apache.activemq.util that return ConnectionContext
 ConnectionContext TransactionTemplate.getContext()
           
 

Methods in org.apache.activemq.util with parameters of type ConnectionContext
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
TransactionTemplate(PersistenceAdapter persistenceAdapter, ConnectionContext context)
           
 



Copyright © 2005-2011 Apache Software Foundation. All Rights Reserved.