Package | Description |
---|---|
org.apache.activemq.advisory | |
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 store
|
org.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 Destinations
|
org.apache.activemq.broker.scheduler |
The Message Scheduler for delayed (or scheduled) message delivery
|
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.memory |
VM based implementation of message persistence
|
org.apache.activemq.transaction | |
org.apache.activemq.util |
Modifier and Type | Method and 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) |
Modifier and Type | Method and Description |
---|---|
ConnectionContext |
ConnectionContext.copy() |
ConnectionContext |
BrokerFilter.getAdminConnectionContext() |
ConnectionContext |
EmptyBroker.getAdminConnectionContext() |
ConnectionContext |
ErrorBroker.getAdminConnectionContext() |
ConnectionContext |
Broker.getAdminConnectionContext() |
ConnectionContext |
MutableBrokerFilter.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() |
Modifier and Type | Method and Description |
---|---|
void |
BrokerFilter.addConnection(ConnectionContext context,
ConnectionInfo info) |
void |
EmptyBroker.addConnection(ConnectionContext context,
ConnectionInfo info) |
void |
ErrorBroker.addConnection(ConnectionContext context,
ConnectionInfo info) |
void |
BrokerBroadcaster.addConnection(ConnectionContext context,
ConnectionInfo info) |
void |
Broker.addConnection(ConnectionContext context,
ConnectionInfo info)
A client is establishing a connection with the broker.
|
void |
MutableBrokerFilter.addConnection(ConnectionContext context,
ConnectionInfo info) |
Subscription |
BrokerFilter.addConsumer(ConnectionContext context,
ConsumerInfo info) |
Subscription |
EmptyBroker.addConsumer(ConnectionContext context,
ConsumerInfo info) |
Subscription |
ErrorBroker.addConsumer(ConnectionContext context,
ConsumerInfo info) |
Subscription |
BrokerBroadcaster.addConsumer(ConnectionContext context,
ConsumerInfo info) |
Subscription |
MutableBrokerFilter.addConsumer(ConnectionContext context,
ConsumerInfo info) |
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) |
Destination |
BrokerBroadcaster.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean createIfTemporary) |
Destination |
MutableBrokerFilter.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean createIfTemporary) |
void |
BrokerFilter.addDestinationInfo(ConnectionContext context,
DestinationInfo info) |
void |
EmptyBroker.addDestinationInfo(ConnectionContext context,
DestinationInfo info) |
void |
ErrorBroker.addDestinationInfo(ConnectionContext context,
DestinationInfo info) |
void |
Broker.addDestinationInfo(ConnectionContext context,
DestinationInfo info)
Add and process a DestinationInfo object
|
void |
MutableBrokerFilter.addDestinationInfo(ConnectionContext context,
DestinationInfo info) |
void |
BrokerFilter.addProducer(ConnectionContext context,
ProducerInfo info) |
void |
EmptyBroker.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 |
BrokerBroadcaster.addProducer(ConnectionContext context,
ProducerInfo info) |
void |
Broker.addProducer(ConnectionContext context,
ProducerInfo info)
Adds a producer.
|
void |
MutableBrokerFilter.addProducer(ConnectionContext context,
ProducerInfo info) |
void |
BrokerFilter.addSession(ConnectionContext context,
SessionInfo info) |
void |
EmptyBroker.addSession(ConnectionContext context,
SessionInfo info) |
void |
ErrorBroker.addSession(ConnectionContext context,
SessionInfo info) |
void |
BrokerBroadcaster.addSession(ConnectionContext context,
SessionInfo info) |
void |
Broker.addSession(ConnectionContext context,
SessionInfo info)
Adds a session.
|
void |
MutableBrokerFilter.addSession(ConnectionContext context,
SessionInfo info) |
void |
BrokerFilter.beginTransaction(ConnectionContext context,
TransactionId xid) |
void |
EmptyBroker.beginTransaction(ConnectionContext context,
TransactionId xid) |
void |
TransactionBroker.beginTransaction(ConnectionContext context,
TransactionId xid) |
void |
ErrorBroker.beginTransaction(ConnectionContext context,
TransactionId xid) |
void |
BrokerBroadcaster.beginTransaction(ConnectionContext context,
TransactionId xid) |
void |
Broker.beginTransaction(ConnectionContext context,
TransactionId xid)
Starts a transaction.
|
void |
MutableBrokerFilter.beginTransaction(ConnectionContext context,
TransactionId xid) |
void |
BrokerFilter.commitTransaction(ConnectionContext context,
TransactionId xid,
boolean onePhase) |
void |
EmptyBroker.commitTransaction(ConnectionContext context,
TransactionId xid,
boolean onePhase) |
void |
TransactionBroker.commitTransaction(ConnectionContext context,
TransactionId xid,
boolean onePhase) |
void |
ErrorBroker.commitTransaction(ConnectionContext context,
TransactionId xid,
boolean onePhase) |
void |
BrokerBroadcaster.commitTransaction(ConnectionContext context,
TransactionId xid,
boolean onePhase) |
void |
Broker.commitTransaction(ConnectionContext context,
TransactionId xid,
boolean onePhase)
Commits a transaction.
|
void |
MutableBrokerFilter.commitTransaction(ConnectionContext context,
TransactionId xid,
boolean onePhase) |
void |
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.fastProducer(ConnectionContext context,
ProducerInfo producerInfo,
ActiveMQDestination destination)
Called to notify a producer is too fast
|
void |
MutableBrokerFilter.fastProducer(ConnectionContext context,
ProducerInfo producerInfo,
ActiveMQDestination destination) |
void |
BrokerFilter.forgetTransaction(ConnectionContext context,
TransactionId transactionId) |
void |
EmptyBroker.forgetTransaction(ConnectionContext context,
TransactionId transactionId) |
void |
TransactionBroker.forgetTransaction(ConnectionContext context,
TransactionId xid) |
void |
ErrorBroker.forgetTransaction(ConnectionContext context,
TransactionId transactionId) |
void |
BrokerBroadcaster.forgetTransaction(ConnectionContext context,
TransactionId transactionId) |
void |
Broker.forgetTransaction(ConnectionContext context,
TransactionId transactionId)
Forgets a transaction.
|
void |
MutableBrokerFilter.forgetTransaction(ConnectionContext context,
TransactionId transactionId) |
TransactionId[] |
BrokerFilter.getPreparedTransactions(ConnectionContext context) |
TransactionId[] |
EmptyBroker.getPreparedTransactions(ConnectionContext context) |
TransactionId[] |
TransactionBroker.getPreparedTransactions(ConnectionContext context) |
TransactionId[] |
ErrorBroker.getPreparedTransactions(ConnectionContext context) |
TransactionId[] |
Broker.getPreparedTransactions(ConnectionContext context)
Gets a list of all the prepared xa transactions.
|
TransactionId[] |
MutableBrokerFilter.getPreparedTransactions(ConnectionContext context) |
Transaction |
TransactionBroker.getTransaction(ConnectionContext context,
TransactionId xid,
boolean mightBePrepared) |
void |
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.isFull(ConnectionContext context,
Destination destination,
Usage usage)
Called when a Usage reaches a limit
|
void |
MutableBrokerFilter.isFull(ConnectionContext context,
Destination destination,
Usage usage) |
void |
BrokerFilter.messageConsumed(ConnectionContext context,
MessageReference messageReference) |
void |
EmptyBroker.messageConsumed(ConnectionContext context,
MessageReference messageReference) |
void |
ErrorBroker.messageConsumed(ConnectionContext context,
MessageReference messageReference) |
void |
Broker.messageConsumed(ConnectionContext context,
MessageReference messageReference)
called when message is consumed
|
void |
MutableBrokerFilter.messageConsumed(ConnectionContext context,
MessageReference messageReference) |
void |
BrokerFilter.messageDelivered(ConnectionContext context,
MessageReference messageReference) |
void |
EmptyBroker.messageDelivered(ConnectionContext context,
MessageReference messageReference) |
void |
ErrorBroker.messageDelivered(ConnectionContext context,
MessageReference messageReference) |
void |
Broker.messageDelivered(ConnectionContext context,
MessageReference messageReference)
Called when message is delivered to the broker
|
void |
MutableBrokerFilter.messageDelivered(ConnectionContext context,
MessageReference messageReference) |
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.messageDiscarded(ConnectionContext context,
Subscription sub,
MessageReference messageReference)
Called when a message is discarded - e.g.
|
void |
MutableBrokerFilter.messageDiscarded(ConnectionContext context,
Subscription sub,
MessageReference messageReference) |
void |
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) |
void |
Broker.messageExpired(ConnectionContext context,
MessageReference messageReference,
Subscription subscription)
A Message has Expired
|
void |
MutableBrokerFilter.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) |
Response |
MutableBrokerFilter.messagePull(ConnectionContext context,
MessagePull pull) |
int |
BrokerFilter.prepareTransaction(ConnectionContext context,
TransactionId xid) |
int |
EmptyBroker.prepareTransaction(ConnectionContext context,
TransactionId xid) |
int |
TransactionBroker.prepareTransaction(ConnectionContext context,
TransactionId xid) |
int |
ErrorBroker.prepareTransaction(ConnectionContext context,
TransactionId xid) |
int |
BrokerBroadcaster.prepareTransaction(ConnectionContext context,
TransactionId xid) |
int |
Broker.prepareTransaction(ConnectionContext context,
TransactionId xid)
Prepares a transaction.
|
int |
MutableBrokerFilter.prepareTransaction(ConnectionContext context,
TransactionId xid) |
void |
BrokerFilter.removeConnection(ConnectionContext context,
ConnectionInfo info,
Throwable error) |
void |
EmptyBroker.removeConnection(ConnectionContext context,
ConnectionInfo info,
Throwable error) |
void |
TransactionBroker.removeConnection(ConnectionContext context,
ConnectionInfo info,
Throwable error) |
void |
ErrorBroker.removeConnection(ConnectionContext context,
ConnectionInfo info,
Throwable error) |
void |
BrokerBroadcaster.removeConnection(ConnectionContext context,
ConnectionInfo info,
Throwable error) |
void |
Broker.removeConnection(ConnectionContext context,
ConnectionInfo info,
Throwable error)
A client is disconnecting from the broker.
|
void |
MutableBrokerFilter.removeConnection(ConnectionContext context,
ConnectionInfo info,
Throwable error) |
void |
BrokerFilter.removeConsumer(ConnectionContext context,
ConsumerInfo info) |
void |
EmptyBroker.removeConsumer(ConnectionContext context,
ConsumerInfo info) |
void |
ErrorBroker.removeConsumer(ConnectionContext context,
ConsumerInfo info) |
void |
BrokerBroadcaster.removeConsumer(ConnectionContext context,
ConsumerInfo info) |
void |
MutableBrokerFilter.removeConsumer(ConnectionContext context,
ConsumerInfo info) |
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 |
BrokerBroadcaster.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
void |
MutableBrokerFilter.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
void |
BrokerFilter.removeDestinationInfo(ConnectionContext context,
DestinationInfo info) |
void |
EmptyBroker.removeDestinationInfo(ConnectionContext context,
DestinationInfo info) |
void |
ErrorBroker.removeDestinationInfo(ConnectionContext context,
DestinationInfo info) |
void |
Broker.removeDestinationInfo(ConnectionContext context,
DestinationInfo info)
Remove and process a DestinationInfo object
|
void |
MutableBrokerFilter.removeDestinationInfo(ConnectionContext context,
DestinationInfo info) |
void |
BrokerFilter.removeProducer(ConnectionContext context,
ProducerInfo info) |
void |
EmptyBroker.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 |
BrokerBroadcaster.removeProducer(ConnectionContext context,
ProducerInfo info) |
void |
Broker.removeProducer(ConnectionContext context,
ProducerInfo info)
Removes a producer.
|
void |
MutableBrokerFilter.removeProducer(ConnectionContext context,
ProducerInfo info) |
void |
BrokerFilter.removeSession(ConnectionContext context,
SessionInfo info) |
void |
EmptyBroker.removeSession(ConnectionContext context,
SessionInfo info) |
void |
ErrorBroker.removeSession(ConnectionContext context,
SessionInfo info) |
void |
BrokerBroadcaster.removeSession(ConnectionContext context,
SessionInfo info) |
void |
Broker.removeSession(ConnectionContext context,
SessionInfo info)
Removes a session.
|
void |
MutableBrokerFilter.removeSession(ConnectionContext context,
SessionInfo info) |
void |
BrokerFilter.removeSubscription(ConnectionContext context,
RemoveSubscriptionInfo info) |
void |
EmptyBroker.removeSubscription(ConnectionContext context,
RemoveSubscriptionInfo info) |
void |
ErrorBroker.removeSubscription(ConnectionContext context,
RemoveSubscriptionInfo info) |
void |
BrokerBroadcaster.removeSubscription(ConnectionContext context,
RemoveSubscriptionInfo info) |
void |
MutableBrokerFilter.removeSubscription(ConnectionContext context,
RemoveSubscriptionInfo info) |
void |
BrokerFilter.rollbackTransaction(ConnectionContext context,
TransactionId xid) |
void |
EmptyBroker.rollbackTransaction(ConnectionContext context,
TransactionId xid) |
void |
TransactionBroker.rollbackTransaction(ConnectionContext context,
TransactionId xid) |
void |
ErrorBroker.rollbackTransaction(ConnectionContext context,
TransactionId xid) |
void |
BrokerBroadcaster.rollbackTransaction(ConnectionContext context,
TransactionId xid) |
void |
Broker.rollbackTransaction(ConnectionContext context,
TransactionId xid)
Rollsback a transaction.
|
void |
MutableBrokerFilter.rollbackTransaction(ConnectionContext context,
TransactionId xid) |
boolean |
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) |
boolean |
Broker.sendToDeadLetterQueue(ConnectionContext context,
MessageReference messageReference,
Subscription subscription,
Throwable poisonCause)
A message needs to go the a DLQ
|
boolean |
MutableBrokerFilter.sendToDeadLetterQueue(ConnectionContext context,
MessageReference messageReference,
Subscription subscription,
Throwable poisonCause) |
void |
BrokerFilter.setAdminConnectionContext(ConnectionContext adminConnectionContext) |
void |
EmptyBroker.setAdminConnectionContext(ConnectionContext adminConnectionContext) |
void |
ErrorBroker.setAdminConnectionContext(ConnectionContext adminConnectionContext) |
void |
Broker.setAdminConnectionContext(ConnectionContext adminConnectionContext)
Sets the default administration connection context used when configuring
the broker on startup or via JMX
|
void |
MutableBrokerFilter.setAdminConnectionContext(ConnectionContext adminConnectionContext) |
void |
ProducerBrokerExchange.setConnectionContext(ConnectionContext connectionContext) |
void |
ConsumerBrokerExchange.setConnectionContext(ConnectionContext connectionContext) |
void |
TransportConnectionState.setContext(ConnectionContext context) |
void |
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.slowConsumer(ConnectionContext context,
Destination destination,
Subscription subs)
Called when there is a slow consumer
|
void |
MutableBrokerFilter.slowConsumer(ConnectionContext context,
Destination dest,
Subscription subs) |
void |
BrokerFilter.virtualDestinationAdded(ConnectionContext context,
VirtualDestination virtualDestination) |
void |
EmptyBroker.virtualDestinationAdded(ConnectionContext context,
VirtualDestination virtualDestination) |
void |
ErrorBroker.virtualDestinationAdded(ConnectionContext context,
VirtualDestination virtualDestination) |
void |
Broker.virtualDestinationAdded(ConnectionContext context,
VirtualDestination virtualDestination) |
void |
MutableBrokerFilter.virtualDestinationAdded(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) |
void |
Broker.virtualDestinationRemoved(ConnectionContext context,
VirtualDestination virtualDestination) |
void |
MutableBrokerFilter.virtualDestinationRemoved(ConnectionContext context,
VirtualDestination virtualDestination) |
Modifier and Type | Method and Description |
---|---|
Subscription |
ConnectionSplitBroker.addConsumer(ConnectionContext context,
ConsumerInfo info) |
void |
ConnectionSplitBroker.removeConsumer(ConnectionContext context,
ConsumerInfo info) |
Modifier and Type | Field and Description |
---|---|
protected ConnectionContext |
AbstractSubscription.context |
Modifier and Type | Method and Description |
---|---|
ConnectionContext |
BaseDestination.createConnectionContext() |
ConnectionContext |
RegionBroker.getAdminConnectionContext() |
ConnectionContext |
RegionBroker.getConnectionContext(String clientId) |
ConnectionContext |
AbstractSubscription.getContext() |
ConnectionContext |
Subscription.getContext() |
Modifier and Type | Method and Description |
---|---|
void |
PrefetchSubscription.acknowledge(ConnectionContext context,
MessageAck ack) |
void |
TopicSubscription.acknowledge(ConnectionContext context,
MessageAck ack) |
void |
AbstractSubscription.acknowledge(ConnectionContext context,
MessageAck ack) |
void |
Subscription.acknowledge(ConnectionContext context,
MessageAck ack)
Used when client acknowledge receipt of dispatched message.
|
protected void |
DurableTopicSubscription.acknowledge(ConnectionContext context,
MessageAck ack,
MessageReference node) |
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 |
QueueBrowserSubscription.acknowledge(ConnectionContext context,
MessageAck ack,
MessageReference n)
Since we are a browser we don't really remove the message from the queue.
|
protected abstract void |
PrefetchSubscription.acknowledge(ConnectionContext context,
MessageAck ack,
MessageReference node)
Used during acknowledgment to remove the message.
|
void |
Destination.acknowledge(ConnectionContext context,
Subscription sub,
MessageAck ack,
MessageReference node) |
void |
Topic.acknowledge(ConnectionContext context,
Subscription sub,
MessageAck ack,
MessageReference node) |
void |
Queue.acknowledge(ConnectionContext context,
Subscription sub,
MessageAck ack,
MessageReference node) |
void |
DestinationFilter.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,
RegionBroker regionBroker) |
void |
DurableTopicSubscription.add(ConnectionContext context,
Destination destination) |
void |
PrefetchSubscription.add(ConnectionContext context,
Destination destination) |
void |
AbstractSubscription.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 |
TopicRegion.addConsumer(ConnectionContext context,
ConsumerInfo info) |
Subscription |
RegionBroker.addConsumer(ConnectionContext context,
ConsumerInfo info) |
Subscription |
Region.addConsumer(ConnectionContext context,
ConsumerInfo info)
Adds a consumer.
|
Subscription |
AbstractRegion.addConsumer(ConnectionContext context,
ConsumerInfo info) |
Destination |
RegionBroker.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean createIfTemp) |
Destination |
Region.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean createIfTemporary)
Used to create a destination.
|
Destination |
AbstractRegion.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean createIfTemporary) |
void |
RegionBroker.addDestinationInfo(ConnectionContext context,
DestinationInfo info) |
void |
RegionBroker.addProducer(ConnectionContext context,
ProducerInfo info) |
void |
BaseDestination.addProducer(ConnectionContext context,
ProducerInfo info) |
void |
Destination.addProducer(ConnectionContext context,
ProducerInfo info) |
void |
Region.addProducer(ConnectionContext context,
ProducerInfo info)
Adds a Producer.
|
void |
DestinationFilter.addProducer(ConnectionContext context,
ProducerInfo info) |
void |
AbstractRegion.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 |
TempQueue.addSubscription(ConnectionContext context,
Subscription sub) |
void |
BaseDestination.addSubscription(ConnectionContext context,
Subscription sub) |
void |
Destination.addSubscription(ConnectionContext context,
Subscription sub) |
void |
TempTopic.addSubscription(ConnectionContext context,
Subscription sub) |
void |
Topic.addSubscription(ConnectionContext context,
Subscription sub) |
void |
Queue.addSubscription(ConnectionContext context,
Subscription sub) |
void |
DestinationFilter.addSubscription(ConnectionContext context,
Subscription sub) |
protected List<Subscription> |
TopicRegion.addSubscriptionsForDestination(ConnectionContext context,
Destination dest) |
protected List<Subscription> |
AbstractRegion.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
|
void |
DestinationInterceptor.create(Broker broker,
ConnectionContext context,
ActiveMQDestination destination) |
void |
CompositeDestinationInterceptor.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 Subscription |
TopicRegion.createSubscription(ConnectionContext context,
ConsumerInfo info) |
protected Subscription |
QueueRegion.createSubscription(ConnectionContext context,
ConsumerInfo info) |
protected Subscription |
TempQueueRegion.createSubscription(ConnectionContext context,
ConsumerInfo info) |
protected abstract Subscription |
AbstractRegion.createSubscription(ConnectionContext context,
ConsumerInfo info) |
protected Subscription |
TempTopicRegion.createSubscription(ConnectionContext context,
ConsumerInfo info) |
void |
Topic.deactivate(ConnectionContext context,
DurableTopicSubscription sub,
List<MessageReference> dispatched) |
void |
Topic.deleteSubscription(ConnectionContext context,
SubscriptionKey key) |
void |
DestinationFilter.deleteSubscription(ConnectionContext context,
SubscriptionKey key) |
protected void |
Topic.dispatch(ConnectionContext context,
Message message) |
void |
TempQueue.dispose(ConnectionContext context) |
void |
BaseDestination.dispose(ConnectionContext context) |
void |
Destination.dispose(ConnectionContext context) |
void |
DestinationFilter.dispose(ConnectionContext context) |
protected void |
AbstractRegion.dispose(ConnectionContext context,
Destination dest) |
protected void |
AbstractTempRegion.dispose(ConnectionContext context,
Destination dest) |
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 fast
|
void |
Destination.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 |
BaseDestination.isFull(ConnectionContext context,
Usage<?> usage)
Called when a Usage reaches a limit
|
void |
Destination.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,
boolean createTemporary) |
void |
BaseDestination.messageConsumed(ConnectionContext context,
MessageReference messageReference)
called when message is consumed
|
void |
Destination.messageConsumed(ConnectionContext context,
MessageReference messageReference)
called when message is consumed
|
void |
DestinationFilter.messageConsumed(ConnectionContext context,
MessageReference messageReference) |
void |
BaseDestination.messageDelivered(ConnectionContext context,
MessageReference messageReference)
Called when message is delivered to the broker
|
void |
Destination.messageDelivered(ConnectionContext context,
MessageReference messageReference)
Called when message is delivered to the broker
|
void |
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 |
Queue.messageExpired(ConnectionContext context,
MessageReference reference) |
void |
RegionBroker.messageExpired(ConnectionContext context,
MessageReference node,
Subscription subscription) |
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 |
Queue.messageExpired(ConnectionContext context,
Subscription subs,
MessageReference reference) |
void |
DestinationFilter.messageExpired(ConnectionContext context,
Subscription subs,
MessageReference node) |
Response |
RegionBroker.messagePull(ConnectionContext context,
MessagePull pull) |
Response |
Region.messagePull(ConnectionContext context,
MessagePull pull)
Allows a consumer to pull a message from a queue
|
Response |
AbstractRegion.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,
QueueMessageReference 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 |
PrefetchSubscription.pullMessage(ConnectionContext context,
MessagePull pull)
Allows a message to be pulled on demand by a client
|
Response |
TopicSubscription.pullMessage(ConnectionContext context,
MessagePull pull) |
Response |
Subscription.pullMessage(ConnectionContext context,
MessagePull pull)
Allows a consumer to pull a message on demand
|
void |
Topic.recoverRetroactiveMessages(ConnectionContext context,
Subscription subscription) |
List<MessageReference> |
QueueBrowserSubscription.remove(ConnectionContext context,
Destination destination) |
List<MessageReference> |
PrefetchSubscription.remove(ConnectionContext context,
Destination destination) |
List<MessageReference> |
AbstractSubscription.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.
|
List<MessageReference> |
PrefetchSubscription.remove(ConnectionContext context,
Destination destination,
List<MessageReference> dispatched) |
void |
RegionBroker.removeConnection(ConnectionContext context,
ConnectionInfo info,
Throwable error) |
void |
TopicRegion.removeConsumer(ConnectionContext context,
ConsumerInfo info) |
void |
RegionBroker.removeConsumer(ConnectionContext context,
ConsumerInfo info) |
void |
Region.removeConsumer(ConnectionContext context,
ConsumerInfo info)
Removes a consumer.
|
void |
AbstractRegion.removeConsumer(ConnectionContext context,
ConsumerInfo info) |
void |
RegionBroker.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
void |
Region.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout)
Used to destroy a destination.
|
void |
TempQueueRegion.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
void |
AbstractRegion.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 |
RegionBroker.removeProducer(ConnectionContext context,
ProducerInfo info) |
void |
BaseDestination.removeProducer(ConnectionContext context,
ProducerInfo info) |
void |
Destination.removeProducer(ConnectionContext context,
ProducerInfo info) |
void |
Region.removeProducer(ConnectionContext context,
ProducerInfo info)
Removes a Producer.
|
void |
DestinationFilter.removeProducer(ConnectionContext context,
ProducerInfo info) |
void |
AbstractRegion.removeProducer(ConnectionContext context,
ProducerInfo info)
Removes a Producer.
|
void |
TopicRegion.removeSubscription(ConnectionContext context,
RemoveSubscriptionInfo info) |
void |
RegionBroker.removeSubscription(ConnectionContext context,
RemoveSubscriptionInfo info) |
void |
Region.removeSubscription(ConnectionContext context,
RemoveSubscriptionInfo info)
Deletes a durable subscription.
|
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 |
Topic.removeSubscription(ConnectionContext context,
Subscription sub,
long lastDeliveredSequenceId) |
void |
Queue.removeSubscription(ConnectionContext context,
Subscription sub,
long lastDeliveredSequenceId) |
void |
DestinationFilter.removeSubscription(ConnectionContext context,
Subscription sub,
long lastDeliveredSequenceId) |
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 consumer
|
void |
Destination.slowConsumer(ConnectionContext context,
Subscription subs)
Called when there is a slow consumer
|
void |
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) |
Constructor and 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) |
Modifier and Type | Method and Description |
---|---|
void |
StoreDurableSubscriberCursor.add(ConnectionContext context,
Destination destination)
Add a destination
|
void |
AbstractPendingMessageCursor.add(ConnectionContext context,
Destination destination) |
void |
PendingMessageCursor.add(ConnectionContext context,
Destination destination)
Add a destination
|
List<MessageReference> |
StoreDurableSubscriberCursor.remove(ConnectionContext context,
Destination destination)
remove a destination
|
List<MessageReference> |
AbstractPendingMessageCursor.remove(ConnectionContext context,
Destination destination) |
List<MessageReference> |
VMPendingMessageCursor.remove(ConnectionContext context,
Destination destination) |
List<MessageReference> |
PendingMessageCursor.remove(ConnectionContext context,
Destination destination)
remove a destination
|
Modifier and Type | Method and Description |
---|---|
boolean |
QueryBasedSubscriptionRecoveryPolicy.add(ConnectionContext context,
MessageReference message) |
boolean |
NoSubscriptionRecoveryPolicy.add(ConnectionContext context,
MessageReference node) |
boolean |
RetainedMessageSubscriptionRecoveryPolicy.add(ConnectionContext context,
MessageReference node) |
boolean |
LastImageSubscriptionRecoveryPolicy.add(ConnectionContext context,
MessageReference node) |
boolean |
FixedCountSubscriptionRecoveryPolicy.add(ConnectionContext context,
MessageReference node) |
boolean |
FixedSizedSubscriptionRecoveryPolicy.add(ConnectionContext context,
MessageReference message) |
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(javax.jms.Message message,
Destination regionDestination,
ConnectionContext context,
SubscriptionRecovery sub) |
void |
QueryBasedSubscriptionRecoveryPolicy.recover(ConnectionContext context,
Topic topic,
SubscriptionRecovery sub) |
void |
NoSubscriptionRecoveryPolicy.recover(ConnectionContext context,
Topic topic,
SubscriptionRecovery sub) |
void |
RetainedMessageSubscriptionRecoveryPolicy.recover(ConnectionContext context,
Topic topic,
SubscriptionRecovery sub) |
void |
LastImageSubscriptionRecoveryPolicy.recover(ConnectionContext context,
Topic topic,
SubscriptionRecovery sub) |
void |
FixedCountSubscriptionRecoveryPolicy.recover(ConnectionContext context,
Topic topic,
SubscriptionRecovery sub) |
void |
FixedSizedSubscriptionRecoveryPolicy.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 |
AbortSlowConsumerStrategy.slowConsumer(ConnectionContext context,
Subscription subs) |
void |
SlowConsumerStrategy.slowConsumer(ConnectionContext context,
Subscription subs)
Slow consumer event.
|
void |
AbortSlowAckConsumerStrategy.slowConsumer(ConnectionContext context,
Subscription subs) |
Modifier and Type | Method and Description |
---|---|
void |
MappedQueueFilter.addSubscription(ConnectionContext context,
Subscription sub) |
void |
MirroredQueue.create(Broker broker,
ConnectionContext context,
ActiveMQDestination destination) |
void |
VirtualDestinationInterceptor.create(Broker broker,
ConnectionContext context,
ActiveMQDestination destination) |
void |
CompositeDestination.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) |
Modifier and Type | Method and Description |
---|---|
protected void |
SchedulerBroker.sendScheduledJob(ConnectionContext context,
Job job,
ActiveMQDestination replyTo) |
Modifier and Type | Method and Description |
---|---|
void |
LoggingBrokerPlugin.addConnection(ConnectionContext context,
ConnectionInfo info) |
void |
UDPTraceBrokerPlugin.addConnection(ConnectionContext context,
ConnectionInfo info) |
Subscription |
LoggingBrokerPlugin.addConsumer(ConnectionContext context,
ConsumerInfo info) |
Subscription |
UDPTraceBrokerPlugin.addConsumer(ConnectionContext context,
ConsumerInfo info) |
Subscription |
DestinationPathSeparatorBroker.addConsumer(ConnectionContext context,
ConsumerInfo info) |
Destination |
DestinationsPlugin.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean createIfTemporary) |
Destination |
LoggingBrokerPlugin.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean create) |
Destination |
DestinationPathSeparatorBroker.addDestination(ConnectionContext context,
ActiveMQDestination destination,
boolean createIfTemporary) |
void |
LoggingBrokerPlugin.addDestinationInfo(ConnectionContext context,
DestinationInfo info) |
void |
UDPTraceBrokerPlugin.addDestinationInfo(ConnectionContext context,
DestinationInfo info) |
void |
DestinationPathSeparatorBroker.addDestinationInfo(ConnectionContext context,
DestinationInfo info) |
void |
LoggingBrokerPlugin.addProducer(ConnectionContext context,
ProducerInfo info) |
void |
UDPTraceBrokerPlugin.addProducer(ConnectionContext context,
ProducerInfo info) |
void |
DestinationPathSeparatorBroker.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 |
LoggingBrokerPlugin.messagePull(ConnectionContext context,
MessagePull pull) |
Response |
UDPTraceBrokerPlugin.messagePull(ConnectionContext context,
MessagePull pull) |
Response |
DestinationPathSeparatorBroker.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 |
LoggingBrokerPlugin.removeConsumer(ConnectionContext context,
ConsumerInfo info) |
void |
UDPTraceBrokerPlugin.removeConsumer(ConnectionContext context,
ConsumerInfo info) |
void |
DestinationPathSeparatorBroker.removeConsumer(ConnectionContext context,
ConsumerInfo info) |
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.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
void |
LoggingBrokerPlugin.removeDestinationInfo(ConnectionContext context,
DestinationInfo info) |
void |
UDPTraceBrokerPlugin.removeDestinationInfo(ConnectionContext context,
DestinationInfo info) |
void |
DestinationPathSeparatorBroker.removeDestinationInfo(ConnectionContext context,
DestinationInfo info) |
void |
LoggingBrokerPlugin.removeProducer(ConnectionContext context,
ProducerInfo info) |
void |
UDPTraceBrokerPlugin.removeProducer(ConnectionContext context,
ProducerInfo info) |
void |
DestinationPathSeparatorBroker.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 |
RedeliveryPlugin.sendToDeadLetterQueue(ConnectionContext context,
MessageReference messageReference,
Subscription subscription,
Throwable poisonCause) |
boolean |
LoggingBrokerPlugin.sendToDeadLetterQueue(ConnectionContext context,
MessageReference messageReference,
Subscription subscription,
Throwable poisonCause) |
void |
LoggingBrokerPlugin.slowConsumer(ConnectionContext context,
Destination destination,
Subscription subs) |
Modifier and Type | Method and 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) |
Modifier and Type | Method and Description |
---|---|
Subscription |
SubQueueSelectorCacheBroker.addConsumer(ConnectionContext context,
ConsumerInfo info) |
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) |
Modifier and Type | Method and Description |
---|---|
void |
JaasCertificateAuthenticationBroker.addConnection(ConnectionContext context,
ConnectionInfo info)
Overridden to allow for authentication based on client certificates.
|
void |
JaasAuthenticationBroker.addConnection(ConnectionContext context,
ConnectionInfo info) |
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 user
|
void |
JaasCertificateAuthenticationBroker.removeConnection(ConnectionContext context,
ConnectionInfo info,
Throwable error)
Overriding removeConnection to make sure the security context is cleaned.
|
void |
AbstractAuthenticationBroker.removeConnection(ConnectionContext context,
ConnectionInfo info,
Throwable error) |
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 |
JaasDualAuthenticationBroker.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
void |
AuthorizationBroker.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout) |
void |
AuthorizationBroker.removeDestinationInfo(ConnectionContext context,
DestinationInfo info) |
Modifier and Type | Field and Description |
---|---|
ConnectionContext |
IndexListener.MessageContext.context |
Modifier and Type | Method and Description |
---|---|
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 checkpoint
|
void |
ProxyTopicMessageStore.acknowledge(ConnectionContext context,
String clientId,
String subscriptionName,
MessageId messageId,
MessageAck ack) |
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 |
ProxyMessageStore.addMessage(ConnectionContext context,
Message message) |
void |
MessageStore.addMessage(ConnectionContext context,
Message message)
Adds a message to the message store
|
void |
ProxyTopicMessageStore.addMessage(ConnectionContext context,
Message message) |
void |
ProxyMessageStore.addMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint) |
void |
MessageStore.addMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint)
Adds a message to the message store
|
void |
ProxyTopicMessageStore.addMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint) |
void |
AbstractMessageStore.addMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint) |
boolean |
ReferenceStore.addMessageReference(ConnectionContext context,
MessageId messageId,
ReferenceStore.ReferenceData data)
Adds a message reference to the message store
|
ListenableFuture<Object> |
ProxyMessageStore.asyncAddQueueMessage(ConnectionContext context,
Message message) |
ListenableFuture<Object> |
MessageStore.asyncAddQueueMessage(ConnectionContext context,
Message message)
Adds a message to the message store
|
ListenableFuture<Object> |
ProxyTopicMessageStore.asyncAddQueueMessage(ConnectionContext context,
Message message) |
ListenableFuture<Object> |
AbstractMessageStore.asyncAddQueueMessage(ConnectionContext context,
Message message) |
ListenableFuture<Object> |
ProxyMessageStore.asyncAddQueueMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint) |
ListenableFuture<Object> |
MessageStore.asyncAddQueueMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint)
Adds a message to the message store
|
ListenableFuture<Object> |
ProxyTopicMessageStore.asyncAddQueueMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint) |
ListenableFuture<Object> |
AbstractMessageStore.asyncAddQueueMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint) |
ListenableFuture<Object> |
ProxyMessageStore.asyncAddTopicMessage(ConnectionContext context,
Message message) |
ListenableFuture<Object> |
MessageStore.asyncAddTopicMessage(ConnectionContext context,
Message message)
Adds a message to the message store
|
ListenableFuture<Object> |
ProxyTopicMessageStore.asyncAddTopicMessage(ConnectionContext context,
Message message) |
ListenableFuture<Object> |
AbstractMessageStore.asyncAddTopicMessage(ConnectionContext context,
Message message) |
ListenableFuture<Object> |
ProxyMessageStore.asyncAddTopicMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint) |
ListenableFuture<Object> |
MessageStore.asyncAddTopicMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint)
Adds a message to the message store
|
ListenableFuture<Object> |
ProxyTopicMessageStore.asyncAddTopicMessage(ConnectionContext context,
Message message,
boolean canOptimizeHint) |
ListenableFuture<Object> |
AbstractMessageStore.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 transaction
|
void |
ProxyMessageStore.dispose(ConnectionContext context) |
void |
MessageStore.dispose(ConnectionContext context) |
void |
ProxyTopicMessageStore.dispose(ConnectionContext context) |
void |
AbstractMessageStore.dispose(ConnectionContext context) |
void |
ProxyMessageStore.removeAllMessages(ConnectionContext context) |
void |
MessageStore.removeAllMessages(ConnectionContext context)
Removes all the messages from the message store.
|
void |
ProxyTopicMessageStore.removeAllMessages(ConnectionContext context) |
void |
ProxyMessageStore.removeAsyncMessage(ConnectionContext context,
MessageAck ack) |
void |
MessageStore.removeAsyncMessage(ConnectionContext context,
MessageAck ack) |
void |
ProxyTopicMessageStore.removeAsyncMessage(ConnectionContext context,
MessageAck ack) |
void |
AbstractMessageStore.removeAsyncMessage(ConnectionContext context,
MessageAck ack) |
void |
ProxyMessageStore.removeMessage(ConnectionContext context,
MessageAck ack) |
void |
MessageStore.removeMessage(ConnectionContext context,
MessageAck ack)
Removes a message from the message store.
|
void |
ProxyTopicMessageStore.removeMessage(ConnectionContext context,
MessageAck ack) |
void |
PersistenceAdapter.rollbackTransaction(ConnectionContext context)
Rollback a persistence transaction
|
Constructor and Description |
---|
IndexListener.MessageContext(ConnectionContext context,
Message message,
Runnable onCompletion) |
Modifier and Type | Method and 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) |
Constructor and Description |
---|
LocalTransaction(TransactionStore transactionStore,
LocalTransactionId xid,
ConnectionContext context) |
Modifier and Type | Method and 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 startup
|
ConnectionContext |
TransactionTemplate.getContext() |
Modifier and Type | Method and 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) |
Constructor and Description |
---|
TransactionTemplate(PersistenceAdapter persistenceAdapter,
ConnectionContext context) |
Copyright © 2005–2020 FuseSource, Corp.. All rights reserved.