|
||||||||||
PREV NEXT | FRAMES NO FRAMES |
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.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 | |
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.util | Some utility Broker Plugins |
org.apache.activemq.broker.view | Broker Plugins for visualising the current system |
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.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.memory | VM based implementation of message persistence |
org.apache.activemq.store.rapid | |
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)
|
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,
ActiveMQTopic topic,
Command command)
|
protected void |
AdvisoryBroker.fireConsumerAdvisory(ConnectionContext context,
ActiveMQTopic topic,
Command command,
ConsumerId targetConsumerId)
|
protected void |
AdvisoryBroker.fireProducerAdvisory(ConnectionContext context,
ActiveMQTopic topic,
Command command)
|
protected void |
AdvisoryBroker.fireProducerAdvisory(ConnectionContext context,
ActiveMQTopic topic,
Command command,
ConsumerId targetConsumerId)
|
void |
AdvisoryBroker.removeConnection(ConnectionContext context,
ConnectionInfo info,
java.lang.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)
|
Uses of ConnectionContext in org.apache.activemq.broker |
---|
Methods in org.apache.activemq.broker that return ConnectionContext | |
---|---|
protected ConnectionContext |
BrokerService.createAdminConnectionContext()
Factory method to create the new administration connection context object. |
ConnectionContext |
Broker.getAdminConnectionContext()
|
ConnectionContext |
MutableBrokerFilter.getAdminConnectionContext()
|
ConnectionContext |
BrokerFilter.getAdminConnectionContext()
|
ConnectionContext |
ErrorBroker.getAdminConnectionContext()
|
ConnectionContext |
EmptyBroker.getAdminConnectionContext()
|
ConnectionContext |
BrokerService.getAdminConnectionContext()
Returns the broker's administration connection context used for configuring the broker at startup |
Uses of ConnectionContext in org.apache.activemq.broker.ft |
---|
Methods in org.apache.activemq.broker.ft with parameters of type ConnectionContext | |
---|---|
void |
MasterBroker.acknowledge(ConnectionContext context,
MessageAck ack)
|
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.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,
java.lang.Throwable error)
A client is disconnecting from the broker. |
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. |
void |
MasterBroker.send(ConnectionContext context,
Message message)
|
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 |
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 |
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 |
Region.acknowledge(ConnectionContext context,
MessageAck ack)
Used to acknowledge the receipt of a message by a client. |
void |
TopicSubscription.acknowledge(ConnectionContext context,
MessageAck ack)
|
void |
RegionBroker.acknowledge(ConnectionContext context,
MessageAck ack)
|
void |
AbstractRegion.acknowledge(ConnectionContext context,
MessageAck ack)
|
void |
PrefetchSubscription.acknowledge(ConnectionContext context,
MessageAck ack)
|
protected void |
DurableTopicSubscription.acknowledge(ConnectionContext context,
MessageAck ack,
MessageReference node)
|
protected 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 |
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 |
Queue.acknowledge(ConnectionContext context,
Subscription sub,
MessageAck ack,
MessageReference node)
|
void |
DestinationFilter.acknowledge(ConnectionContext context,
Subscription sub,
MessageAck ack,
MessageReference node)
|
void |
Topic.acknowledge(ConnectionContext context,
Subscription sub,
MessageAck ack,
MessageReference node)
|
void |
DurableTopicSubscription.activate(ConnectionContext context,
ConsumerInfo info)
|
void |
Topic.activate(ConnectionContext context,
DurableTopicSubscription subscription)
|
void |
Subscription.add(ConnectionContext context,
Destination destination)
The subscription will be receiving messages from the destination. |
void |
AbstractSubscription.add(ConnectionContext context,
Destination destination)
|
void |
DurableTopicSubscription.add(ConnectionContext context,
Destination destination)
|
void |
PrefetchSubscription.add(ConnectionContext context,
Destination destination)
|
void |
RegionBroker.addConnection(ConnectionContext context,
ConnectionInfo info)
|
Subscription |
Region.addConsumer(ConnectionContext context,
ConsumerInfo info)
Adds a consumer. |
Subscription |
RegionBroker.addConsumer(ConnectionContext context,
ConsumerInfo info)
|
Subscription |
AbstractRegion.addConsumer(ConnectionContext context,
ConsumerInfo info)
|
Subscription |
TopicRegion.addConsumer(ConnectionContext context,
ConsumerInfo info)
|
Destination |
Region.addDestination(ConnectionContext context,
ActiveMQDestination destination)
Used to create a destination. |
Destination |
RegionBroker.addDestination(ConnectionContext context,
ActiveMQDestination destination)
|
Destination |
AbstractRegion.addDestination(ConnectionContext context,
ActiveMQDestination destination)
|
void |
RegionBroker.addDestinationInfo(ConnectionContext context,
DestinationInfo info)
|
void |
RegionBroker.addProducer(ConnectionContext context,
ProducerInfo info)
|
void |
RegionBroker.addSession(ConnectionContext context,
SessionInfo info)
|
void |
Destination.addSubscription(ConnectionContext context,
Subscription sub)
|
void |
Queue.addSubscription(ConnectionContext context,
Subscription sub)
|
void |
DestinationFilter.addSubscription(ConnectionContext context,
Subscription sub)
|
void |
Topic.addSubscription(ConnectionContext context,
Subscription sub)
|
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,
java.lang.String selector,
ActiveMQDestination dest)
Copies the messages matching the given selector |
int |
Queue.copyMatchingMessagesTo(ConnectionContext context,
java.lang.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,
java.lang.String messageId,
ActiveMQDestination dest)
Copies the message matching the given messageId |
protected Destination |
AbstractRegion.createDestination(ConnectionContext context,
ActiveMQDestination destination)
|
protected Destination |
TempQueueRegion.createDestination(ConnectionContext context,
ActiveMQDestination destination)
|
protected Destination |
TopicRegion.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 |
TempQueueRegion.createSubscription(ConnectionContext context,
ConsumerInfo info)
|
protected Subscription |
QueueRegion.createSubscription(ConnectionContext context,
ConsumerInfo info)
|
protected Subscription |
TopicRegion.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 |
Queue.dispose(ConnectionContext context)
|
void |
DestinationFilter.dispose(ConnectionContext context)
|
void |
Topic.dispose(ConnectionContext context)
|
boolean |
MessageReferenceFilter.evaluate(ConnectionContext context,
MessageReference messageReference)
|
void |
RegionBroker.forgetTransaction(ConnectionContext context,
TransactionId transactionId)
|
TransactionId[] |
RegionBroker.getPreparedTransactions(ConnectionContext context)
|
protected Destination |
AbstractRegion.lookup(ConnectionContext context,
ActiveMQDestination destination)
|
Response |
Region.messagePull(ConnectionContext context,
MessagePull pull)
Allows a consumer to pull a message from a queue |
Response |
RegionBroker.messagePull(ConnectionContext context,
MessagePull pull)
|
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,
java.lang.String selector,
ActiveMQDestination dest)
Moves the messages matching the given selector |
int |
Queue.moveMatchingMessagesTo(ConnectionContext context,
java.lang.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,
java.lang.String messageId,
ActiveMQDestination dest)
Moves the message matching the given messageId |
protected void |
Topic.onMessageWithNoConsumers(ConnectionContext context,
Message message)
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 |
TopicSubscription.pullMessage(ConnectionContext context,
MessagePull pull)
|
Response |
PrefetchSubscription.pullMessage(ConnectionContext context,
MessagePull pull)
Allows a message to be pulled on demand by a client |
void |
Subscription.remove(ConnectionContext context,
Destination destination)
The subscription will be no longer be receiving messages from the destination. |
void |
AbstractSubscription.remove(ConnectionContext context,
Destination destination)
|
void |
PrefetchSubscription.remove(ConnectionContext context,
Destination destination)
|
void |
RegionBroker.removeConnection(ConnectionContext context,
ConnectionInfo info,
java.lang.Throwable error)
|
void |
Region.removeConsumer(ConnectionContext context,
ConsumerInfo info)
Removes a consumer. |
void |
RegionBroker.removeConsumer(ConnectionContext context,
ConsumerInfo info)
|
void |
AbstractRegion.removeConsumer(ConnectionContext context,
ConsumerInfo info)
|
void |
TopicRegion.removeConsumer(ConnectionContext context,
ConsumerInfo info)
|
void |
Region.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout)
Used to destroy a destination. |
void |
RegionBroker.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout)
|
void |
AbstractRegion.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout)
|
void |
TempQueueRegion.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout)
|
void |
TempTopicRegion.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout)
|
void |
RegionBroker.removeDestinationInfo(ConnectionContext context,
DestinationInfo info)
|
protected void |
Queue.removeMessage(ConnectionContext c,
IndirectMessageReference r)
|
void |
RegionBroker.removeProducer(ConnectionContext context,
ProducerInfo info)
|
void |
RegionBroker.removeSession(ConnectionContext context,
SessionInfo info)
|
void |
Region.removeSubscription(ConnectionContext context,
RemoveSubscriptionInfo info)
Deletes a durable subscription. |
void |
RegionBroker.removeSubscription(ConnectionContext context,
RemoveSubscriptionInfo info)
|
void |
AbstractRegion.removeSubscription(ConnectionContext context,
RemoveSubscriptionInfo info)
|
void |
TopicRegion.removeSubscription(ConnectionContext context,
RemoveSubscriptionInfo info)
|
void |
Destination.removeSubscription(ConnectionContext context,
Subscription sub)
|
void |
Queue.removeSubscription(ConnectionContext context,
Subscription sub)
|
void |
DestinationFilter.removeSubscription(ConnectionContext context,
Subscription sub)
|
void |
Topic.removeSubscription(ConnectionContext context,
Subscription sub)
|
void |
RegionBroker.rollbackTransaction(ConnectionContext context,
TransactionId xid)
|
void |
Destination.send(ConnectionContext context,
Message messageSend)
|
void |
Region.send(ConnectionContext context,
Message message)
Send a message to the broker to using the specified destination. |
void |
RegionBroker.send(ConnectionContext context,
Message message)
|
void |
Queue.send(ConnectionContext context,
Message message)
|
void |
AbstractRegion.send(ConnectionContext context,
Message messageSend)
|
void |
DestinationFilter.send(ConnectionContext context,
Message messageSend)
|
void |
Topic.send(ConnectionContext context,
Message message)
|
protected void |
DestinationFilter.send(ConnectionContext context,
Message message,
ActiveMQDestination destination)
Sends a message to the given destination which may be a wildcard |
protected void |
PrefetchSubscription.sendToDLQ(ConnectionContext context,
MessageReference node)
|
protected void |
QueueSubscription.sendToDLQ(ConnectionContext context,
MessageReference node)
Sending a message to the DQL will require us to increment the ref count so we can get at the content. |
void |
RegionBroker.setAdminConnectionContext(ConnectionContext adminConnectionContext)
|
Constructors in org.apache.activemq.broker.region with parameters of type ConnectionContext | |
---|---|
AbstractSubscription(Broker broker,
ConnectionContext context,
ConsumerInfo info)
|
|
DurableTopicSubscription(Broker broker,
ConnectionContext context,
ConsumerInfo info,
boolean keepDurableSubsActive,
PendingMessageCursor cursor)
|
|
PrefetchSubscription(Broker broker,
ConnectionContext context,
ConsumerInfo info)
|
|
PrefetchSubscription(Broker broker,
ConnectionContext context,
ConsumerInfo info,
PendingMessageCursor cursor)
|
|
QueueBrowserSubscription(Broker broker,
ConnectionContext context,
ConsumerInfo info)
|
|
QueueSubscription(Broker broker,
ConnectionContext context,
ConsumerInfo info)
|
|
TopicSubscription(Broker broker,
ConnectionContext context,
ConsumerInfo info,
UsageManager 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 |
void |
PendingMessageCursor.remove(ConnectionContext context,
Destination destination)
remove a destination |
void |
AbstractPendingMessageCursor.remove(ConnectionContext context,
Destination destination)
|
void |
StoreDurableSubscriberCursor.remove(ConnectionContext context,
Destination destination)
remove a 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 |
NoSubscriptionRecoveryPolicy.add(ConnectionContext context,
MessageReference node)
|
boolean |
SubscriptionRecoveryPolicy.add(ConnectionContext context,
MessageReference message)
A message was sent to the destination. |
boolean |
FixedCountSubscriptionRecoveryPolicy.add(ConnectionContext context,
MessageReference node)
|
boolean |
TimedSubscriptionRecoveryPolicy.add(ConnectionContext context,
MessageReference message)
|
boolean |
FixedSizedSubscriptionRecoveryPolicy.add(ConnectionContext context,
MessageReference message)
|
boolean |
QueryBasedSubscriptionRecoveryPolicy.add(ConnectionContext context,
MessageReference message)
|
boolean |
LastImageSubscriptionRecoveryPolicy.add(ConnectionContext context,
MessageReference node)
|
boolean |
DispatchPolicy.dispatch(ConnectionContext newParam,
MessageReference node,
MessageEvaluationContext msgContext,
java.util.List consumers)
Decides how to dispatch a selected message to a collection of consumers. |
boolean |
RoundRobinDispatchPolicy.dispatch(ConnectionContext newParam,
MessageReference node,
MessageEvaluationContext msgContext,
java.util.List consumers)
|
boolean |
StrictOrderDispatchPolicy.dispatch(ConnectionContext newParam,
MessageReference node,
MessageEvaluationContext msgContext,
java.util.List consumers)
|
boolean |
SimpleDispatchPolicy.dispatch(ConnectionContext context,
MessageReference node,
MessageEvaluationContext msgContext,
java.util.List consumers)
|
void |
NoSubscriptionRecoveryPolicy.recover(ConnectionContext context,
Topic topic,
Subscription sub)
|
void |
SubscriptionRecoveryPolicy.recover(ConnectionContext context,
Topic topic,
Subscription sub)
Let a subscription recover message held by the policy. |
void |
FixedCountSubscriptionRecoveryPolicy.recover(ConnectionContext context,
Topic topic,
Subscription sub)
|
void |
TimedSubscriptionRecoveryPolicy.recover(ConnectionContext context,
Topic topic,
Subscription sub)
|
void |
FixedSizedSubscriptionRecoveryPolicy.recover(ConnectionContext context,
Topic topic,
Subscription sub)
|
void |
QueryBasedSubscriptionRecoveryPolicy.recover(ConnectionContext context,
Topic topic,
Subscription sub)
|
void |
LastImageSubscriptionRecoveryPolicy.recover(ConnectionContext context,
Topic topic,
Subscription sub)
|
Uses of ConnectionContext in org.apache.activemq.broker.region.virtual |
---|
Methods in org.apache.activemq.broker.region.virtual with parameters of type ConnectionContext | |
---|---|
void |
CompositeDestinationInterceptor.send(ConnectionContext context,
Message message)
|
void |
VirtualTopicInterceptor.send(ConnectionContext context,
Message message)
|
Uses of ConnectionContext in org.apache.activemq.broker.util |
---|
Methods in org.apache.activemq.broker.util with parameters of type ConnectionContext | |
---|---|
void |
LoggingBrokerPlugin.acknowledge(ConnectionContext context,
MessageAck ack)
|
void |
UDPTraceBrokerPlugin.acknowledge(ConnectionContext context,
MessageAck ack)
|
void |
UDPTraceBrokerPlugin.addConnection(ConnectionContext context,
ConnectionInfo info)
|
Subscription |
UDPTraceBrokerPlugin.addConsumer(ConnectionContext context,
ConsumerInfo info)
|
void |
UDPTraceBrokerPlugin.addDestinationInfo(ConnectionContext context,
DestinationInfo info)
|
void |
UDPTraceBrokerPlugin.addProducer(ConnectionContext context,
ProducerInfo info)
|
void |
UDPTraceBrokerPlugin.addSession(ConnectionContext context,
SessionInfo info)
|
void |
UDPTraceBrokerPlugin.beginTransaction(ConnectionContext context,
TransactionId xid)
|
void |
UDPTraceBrokerPlugin.commitTransaction(ConnectionContext context,
TransactionId xid,
boolean onePhase)
|
void |
UDPTraceBrokerPlugin.forgetTransaction(ConnectionContext context,
TransactionId xid)
|
Response |
UDPTraceBrokerPlugin.messagePull(ConnectionContext context,
MessagePull pull)
|
int |
UDPTraceBrokerPlugin.prepareTransaction(ConnectionContext context,
TransactionId xid)
|
void |
UDPTraceBrokerPlugin.removeConnection(ConnectionContext context,
ConnectionInfo info,
java.lang.Throwable error)
|
void |
UDPTraceBrokerPlugin.removeConsumer(ConnectionContext context,
ConsumerInfo info)
|
void |
UDPTraceBrokerPlugin.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout)
|
void |
UDPTraceBrokerPlugin.removeDestinationInfo(ConnectionContext context,
DestinationInfo info)
|
void |
UDPTraceBrokerPlugin.removeProducer(ConnectionContext context,
ProducerInfo info)
|
void |
UDPTraceBrokerPlugin.removeSession(ConnectionContext context,
SessionInfo info)
|
void |
UDPTraceBrokerPlugin.removeSubscription(ConnectionContext context,
RemoveSubscriptionInfo info)
|
void |
UDPTraceBrokerPlugin.rollbackTransaction(ConnectionContext context,
TransactionId xid)
|
void |
LoggingBrokerPlugin.send(ConnectionContext context,
Message messageSend)
|
void |
TimeStampingBrokerPlugin.send(ConnectionContext context,
Message message)
|
void |
UDPTraceBrokerPlugin.send(ConnectionContext context,
Message messageSend)
|
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)
|
void |
ConnectionDotFileInterceptor.send(ConnectionContext context,
Message messageSend)
|
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 |
SimpleAuthenticationBroker.addConnection(ConnectionContext context,
ConnectionInfo info)
|
void |
JaasCertificateAuthenticationBroker.addConnection(ConnectionContext context,
ConnectionInfo info)
Overridden to allow for authentication based on client certificates. |
Subscription |
AuthorizationBroker.addConsumer(ConnectionContext context,
ConsumerInfo info)
|
Destination |
AuthorizationBroker.addDestination(ConnectionContext context,
ActiveMQDestination destination)
|
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,
java.lang.Throwable error)
|
void |
SimpleAuthenticationBroker.removeConnection(ConnectionContext context,
ConnectionInfo info,
java.lang.Throwable error)
|
void |
JaasCertificateAuthenticationBroker.removeConnection(ConnectionContext context,
ConnectionInfo info,
java.lang.Throwable error)
Overriding removeConnection to make sure the security context is cleaned. |
void |
AuthorizationBroker.removeDestination(ConnectionContext context,
ActiveMQDestination destination,
long timeout)
|
void |
AuthorizationBroker.send(ConnectionContext context,
Message messageSend)
|
Uses of ConnectionContext in org.apache.activemq.store |
---|
Methods in org.apache.activemq.store with parameters of type ConnectionContext | |
---|---|
void |
TopicMessageStore.acknowledge(ConnectionContext context,
java.lang.String clientId,
java.lang.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,
java.lang.String clientId,
java.lang.String subscriptionName,
MessageId messageId)
|
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)
|
void |
MessageStore.addMessageReference(ConnectionContext context,
MessageId messageId,
long expirationTime,
java.lang.String messageRef)
Adds a message reference to the message store |
void |
ProxyTopicMessageStore.addMessageReference(ConnectionContext context,
MessageId messageId,
long expirationTime,
java.lang.String messageRef)
|
void |
ProxyMessageStore.addMessageReference(ConnectionContext context,
MessageId messageId,
long expirationTime,
java.lang.String messageRef)
|
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.removeAllMessages(ConnectionContext context)
Removes all the messages from the message store. |
void |
ProxyTopicMessageStore.removeAllMessages(ConnectionContext context)
|
void |
ProxyMessageStore.removeAllMessages(ConnectionContext context)
|
void |
MessageStore.removeMessage(ConnectionContext context,
MessageAck ack)
Removes a message from the message store. |
void |
ProxyTopicMessageStore.removeMessage(ConnectionContext context,
MessageAck ack)
|
void |
ProxyMessageStore.removeMessage(ConnectionContext context,
MessageAck ack)
|
void |
PersistenceAdapter.rollbackTransaction(ConnectionContext context)
Rollback a persistence transaction |
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,
java.lang.String clientId,
java.lang.String subscriptionName,
MessageId messageId)
|
void |
JDBCMessageStore.addMessage(ConnectionContext context,
Message message)
|
void |
JDBCMessageStore.addMessageReference(ConnectionContext context,
MessageId messageId,
long expirationTime,
java.lang.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 |
QuickJournalTopicMessageStore.acknowledge(ConnectionContext context,
java.lang.String clientId,
java.lang.String subscriptionName,
MessageId messageId)
|
void |
JournalTopicMessageStore.acknowledge(ConnectionContext context,
java.lang.String clientId,
java.lang.String subscriptionName,
MessageId messageId)
|
void |
QuickJournalMessageStore.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 |
QuickJournalTopicMessageStore.addMessage(ConnectionContext context,
Message message)
|
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 |
QuickJournalMessageStore.addMessageReference(ConnectionContext context,
MessageId messageId,
long expirationTime,
java.lang.String messageRef)
|
void |
JournalMessageStore.addMessageReference(ConnectionContext context,
MessageId messageId,
long expirationTime,
java.lang.String messageRef)
|
void |
QuickJournalPersistenceAdapter.beginTransaction(ConnectionContext context)
|
void |
JournalPersistenceAdapter.beginTransaction(ConnectionContext context)
|
void |
QuickJournalPersistenceAdapter.commitTransaction(ConnectionContext context)
|
void |
JournalPersistenceAdapter.commitTransaction(ConnectionContext context)
|
void |
QuickJournalMessageStore.removeAllMessages(ConnectionContext context)
|
void |
JournalMessageStore.removeAllMessages(ConnectionContext context)
|
void |
QuickJournalMessageStore.removeMessage(ConnectionContext context,
MessageAck ack)
|
void |
JournalMessageStore.removeMessage(ConnectionContext context,
MessageAck ack)
|
void |
QuickJournalTopicMessageStore.replayAcknowledge(ConnectionContext context,
java.lang.String clientId,
java.lang.String subscritionName,
MessageId messageId)
|
void |
JournalTopicMessageStore.replayAcknowledge(ConnectionContext context,
java.lang.String clientId,
java.lang.String subscritionName,
MessageId messageId)
|
void |
JournalMessageStore.replayAddMessage(ConnectionContext context,
Message message)
|
void |
QuickJournalMessageStore.replayAddMessage(ConnectionContext context,
Message message,
org.apache.activeio.journal.RecordLocation location)
|
void |
QuickJournalMessageStore.replayRemoveMessage(ConnectionContext context,
MessageAck messageAck)
|
void |
JournalMessageStore.replayRemoveMessage(ConnectionContext context,
MessageAck messageAck)
|
void |
QuickJournalPersistenceAdapter.rollbackTransaction(ConnectionContext context)
|
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,
java.lang.String clientId,
java.lang.String subscriptionName,
MessageId messageId)
|
void |
KahaTopicMessageStore.addMessage(ConnectionContext context,
Message message)
|
void |
KahaMessageStore.addMessage(ConnectionContext context,
Message message)
|
void |
KahaTopicMessageStore.addMessageReference(ConnectionContext context,
MessageId messageId,
long expirationTime,
java.lang.String messageRef)
|
void |
KahaMessageStore.addMessageReference(ConnectionContext context,
MessageId messageId,
long expirationTime,
java.lang.String messageRef)
|
void |
KahaPersistenceAdapter.beginTransaction(ConnectionContext context)
|
void |
KahaPersistenceAdapter.commitTransaction(ConnectionContext context)
|
void |
KahaTopicMessageStore.removeAllMessages(ConnectionContext context)
|
void |
KahaMessageStore.removeAllMessages(ConnectionContext context)
|
void |
KahaTopicMessageStore.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.memory |
---|
Methods in org.apache.activemq.store.memory with parameters of type ConnectionContext | |
---|---|
void |
MemoryTopicMessageStore.acknowledge(ConnectionContext context,
java.lang.String clientId,
java.lang.String subscriptionName,
MessageId messageId)
|
void |
MemoryMessageStore.addMessage(ConnectionContext context,
Message message)
|
void |
MemoryTopicMessageStore.addMessage(ConnectionContext context,
Message message)
|
void |
MemoryMessageStore.addMessageReference(ConnectionContext context,
MessageId messageId,
long expirationTime,
java.lang.String messageRef)
|
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)
|
Uses of ConnectionContext in org.apache.activemq.store.rapid |
---|
Methods in org.apache.activemq.store.rapid with parameters of type ConnectionContext | |
---|---|
void |
RapidTopicMessageStore.acknowledge(ConnectionContext context,
java.lang.String clientId,
java.lang.String subscriptionName,
MessageId messageId)
|
void |
RapidMessageStore.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 |
RapidTopicMessageStore.addMessage(ConnectionContext context,
Message message)
|
void |
RapidMessageStore.addMessageReference(ConnectionContext context,
MessageId messageId,
long expirationTime,
java.lang.String messageRef)
|
void |
RapidPersistenceAdapter.beginTransaction(ConnectionContext context)
|
void |
RapidPersistenceAdapter.commitTransaction(ConnectionContext context)
|
void |
RapidMessageStore.removeAllMessages(ConnectionContext context)
|
void |
RapidMessageStore.removeMessage(ConnectionContext context,
MessageAck ack)
|
void |
RapidTopicMessageStore.replayAcknowledge(ConnectionContext context,
java.lang.String clientId,
java.lang.String subscritionName,
MessageId messageId)
|
void |
RapidMessageStore.replayAddMessage(ConnectionContext context,
Message message,
org.apache.activeio.journal.RecordLocation location)
|
void |
RapidMessageStore.replayRemoveMessage(ConnectionContext context,
MessageAck ack)
|
void |
RapidPersistenceAdapter.rollbackTransaction(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.resend(ConnectionContext context,
Message message,
ActiveMQDestination deadLetterDestination)
|
Constructors in org.apache.activemq.util with parameters of type ConnectionContext | |
---|---|
TransactionTemplate(PersistenceAdapter persistenceAdapter,
ConnectionContext context)
|
|
||||||||||
PREV NEXT | FRAMES NO FRAMES |