|
|||||||||||
PREV NEXT | FRAMES NO FRAMES |
Packages that use BrokerClient | |
org.activemq.broker | The API for the JMS Broker which is the server side of a JMS network though it may be deployed inside a client in peer style networks. |
org.activemq.broker.impl | The default implementation of the JMS Broker |
org.activemq.security | Plugable Security Adapter framework along with default implementations such as the JAAS implementation. |
org.activemq.security.jassjacc | |
org.activemq.service | The core services which make up the JMS Message Broker such as the Store, MessageContainer and MessageContainerManager |
org.activemq.service.boundedvm | |
org.activemq.service.impl | Default implementations of the services |
org.activemq.transport | The transport abstraction layer for sending and receiving Packets over a network |
Uses of BrokerClient in org.activemq.broker |
Methods in org.activemq.broker with parameters of type BrokerClient | |
void |
ConsumerInfoListener.onConsumerInfo(BrokerClient client,
ConsumerInfo info)
ConsumerInfo packet fired from within the broker |
void |
Broker.addClient(BrokerClient client,
ConnectionInfo info)
Notification of a new client attempting to connect, which can be rejected if authentication or authorization fails. |
void |
Broker.removeClient(BrokerClient client,
ConnectionInfo info)
A hint to the broker that an BrokerClient has stopped This enables the broker to clean-up any outstanding processing that may be outstanding |
void |
Broker.addMessageProducer(BrokerClient client,
ProducerInfo info)
Adds a new message producer, which could be rejected due to authorization |
void |
Broker.removeMessageProducer(BrokerClient client,
ProducerInfo info)
Removes a producer |
void |
Broker.addMessageConsumer(BrokerClient client,
ConsumerInfo info)
Add an active message consumer, which could be rejected due to authorization |
void |
Broker.removeMessageConsumer(BrokerClient client,
ConsumerInfo info)
remove an active message consumer |
void |
Broker.sendMessage(BrokerClient client,
ActiveMQMessage message)
send a message to the broker |
void |
Broker.acknowledgeMessage(BrokerClient client,
MessageAck ack)
Acknowledge positively or negatively, the consumption of a message by the Message Consumer |
ActiveMQXid[] |
Broker.getPreparedTransactions(BrokerClient client)
gets a list of all the prepared xa transactions. |
void |
Broker.startTransaction(BrokerClient client,
String transactionId)
start a transaction |
void |
Broker.commitTransaction(BrokerClient client,
String transactionId)
commit a transaction |
void |
Broker.rollbackTransaction(BrokerClient client,
String transactionId)
rollback a transaction |
void |
Broker.startTransaction(BrokerClient client,
ActiveMQXid xid)
|
int |
Broker.prepareTransaction(BrokerClient client,
ActiveMQXid xid)
|
void |
Broker.rollbackTransaction(BrokerClient client,
ActiveMQXid xid)
|
void |
Broker.commitTransaction(BrokerClient client,
ActiveMQXid xid,
boolean onePhase)
|
void |
BrokerConnector.registerClient(BrokerClient client,
ConnectionInfo info)
Register a Broker Client |
void |
BrokerConnector.deregisterClient(BrokerClient client,
ConnectionInfo info)
Deregister a Broker Client |
void |
BrokerConnector.registerMessageConsumer(BrokerClient client,
ConsumerInfo info)
Registers a MessageConsumer |
void |
BrokerConnector.deregisterMessageConsumer(BrokerClient client,
ConsumerInfo info)
De-register a MessageConsumer from the Broker |
void |
BrokerConnector.registerMessageProducer(BrokerClient client,
ProducerInfo info)
Registers a MessageProducer |
void |
BrokerConnector.deregisterMessageProducer(BrokerClient client,
ProducerInfo info)
De-register a MessageProducer from the Broker |
void |
BrokerConnector.registerSession(BrokerClient client,
SessionInfo info)
Register a client-side Session (used for Monitoring) |
void |
BrokerConnector.deregisterSession(BrokerClient client,
SessionInfo info)
De-register a client-side Session from the Broker (used for monitoring) |
void |
BrokerConnector.startTransaction(BrokerClient client,
String transactionId)
Start a transaction from the Client session |
void |
BrokerConnector.rollbackTransaction(BrokerClient client,
String transactionId)
Rollback a transacton |
void |
BrokerConnector.commitTransaction(BrokerClient client,
String transactionId)
Commit a transaction |
void |
BrokerConnector.startTransaction(BrokerClient client,
ActiveMQXid xid)
Start an XA transaction |
ActiveMQXid[] |
BrokerConnector.getPreparedTransactions(BrokerClient client)
Get all the Xids of the prepared XA transactions. |
int |
BrokerConnector.prepareTransaction(BrokerClient client,
ActiveMQXid xid)
Prepare an XA transaction. |
void |
BrokerConnector.rollbackTransaction(BrokerClient client,
ActiveMQXid xid)
Rollback an XA transaction. |
void |
BrokerConnector.commitTransaction(BrokerClient client,
ActiveMQXid xid,
boolean onePhase)
Commit an XA transaction. |
void |
BrokerConnector.sendMessage(BrokerClient client,
ActiveMQMessage message)
Send a non-transacted message to the Broker |
void |
BrokerConnector.acknowledgeMessage(BrokerClient client,
MessageAck ack)
Acknowledge reciept of a message |
void |
BrokerConnector.durableUnsubscribe(BrokerClient client,
DurableUnsubscribe ds)
Command to delete a durable topic subscription |
String |
BrokerConnector.getResourceManagerId(BrokerClient client)
Gets the unique id of the resource manager used for managing xa transactions. |
void |
BrokerContainer.registerConnection(BrokerClient client,
ConnectionInfo info)
registers a new Connection |
void |
BrokerContainer.deregisterConnection(BrokerClient client,
ConnectionInfo info)
un-registers a Connection |
void |
BrokerContainer.registerMessageConsumer(BrokerClient client,
ConsumerInfo info)
Registers a MessageConsumer |
void |
BrokerContainer.deregisterMessageConsumer(BrokerClient client,
ConsumerInfo info)
De-register a MessageConsumer from the Broker |
void |
BrokerContainer.registerMessageProducer(BrokerClient client,
ProducerInfo info)
Registers a MessageProducer |
void |
BrokerContainer.deregisterMessageProducer(BrokerClient client,
ProducerInfo info)
De-register a MessageProducer from the Broker |
void |
BrokerContainer.registerSession(BrokerClient client,
SessionInfo info)
Register a client-side Session (used for Monitoring) |
void |
BrokerContainer.deregisterSession(BrokerClient client,
SessionInfo info)
De-register a client-side Session from the Broker (used for monitoring) |
void |
BrokerContainer.startTransaction(BrokerClient client,
String transactionId)
Start a transaction from the Client session |
void |
BrokerContainer.rollbackTransaction(BrokerClient client,
String transactionId)
Rollback a transacton |
void |
BrokerContainer.commitTransaction(BrokerClient client,
String transactionId)
Commit a transaction |
void |
BrokerContainer.sendMessage(BrokerClient client,
ActiveMQMessage message)
Send a non-transacted message to the Broker |
void |
BrokerContainer.acknowledgeMessage(BrokerClient client,
MessageAck ack)
Acknowledge reciept of a message |
void |
BrokerContainer.durableUnsubscribe(BrokerClient client,
DurableUnsubscribe ds)
Command to delete a durable topic subscription |
void |
BrokerContainer.startTransaction(BrokerClient client,
ActiveMQXid xid)
Start an XA transaction. |
ActiveMQXid[] |
BrokerContainer.getPreparedTransactions(BrokerClient client)
Gets the prepared XA transactions. |
int |
BrokerContainer.prepareTransaction(BrokerClient client,
ActiveMQXid xid)
Prepare an XA transaction. |
void |
BrokerContainer.rollbackTransaction(BrokerClient client,
ActiveMQXid xid)
Rollback an XA transaction. |
void |
BrokerContainer.commitTransaction(BrokerClient client,
ActiveMQXid xid,
boolean onePhase)
Commit an XA transaction. |
Uses of BrokerClient in org.activemq.broker.impl |
Classes in org.activemq.broker.impl that implement BrokerClient | |
class |
BrokerClientImpl
A Broker client side proxy representing a JMS Connnection |
Methods in org.activemq.broker.impl with parameters of type BrokerClient | |
void |
BrokerConnectorImpl.registerClient(BrokerClient client,
ConnectionInfo info)
Register a Broker Client |
void |
BrokerConnectorImpl.deregisterClient(BrokerClient client,
ConnectionInfo info)
Deregister a Broker Client |
void |
BrokerConnectorImpl.registerMessageConsumer(BrokerClient client,
ConsumerInfo info)
Registers a MessageConsumer |
void |
BrokerConnectorImpl.deregisterMessageConsumer(BrokerClient client,
ConsumerInfo info)
De-register a MessageConsumer from the Broker |
void |
BrokerConnectorImpl.registerMessageProducer(BrokerClient client,
ProducerInfo info)
Registers a MessageProducer |
void |
BrokerConnectorImpl.deregisterMessageProducer(BrokerClient client,
ProducerInfo info)
De-register a MessageProducer from the Broker |
void |
BrokerConnectorImpl.registerSession(BrokerClient client,
SessionInfo info)
Register a client-side Session (used for Monitoring) |
void |
BrokerConnectorImpl.deregisterSession(BrokerClient client,
SessionInfo info)
De-register a client-side Session from the Broker (used for monitoring) |
void |
BrokerConnectorImpl.startTransaction(BrokerClient client,
String transactionId)
Start a transaction from the Client session |
void |
BrokerConnectorImpl.rollbackTransaction(BrokerClient client,
String transactionId)
Rollback a transacton |
void |
BrokerConnectorImpl.commitTransaction(BrokerClient client,
String transactionId)
Commit a transaction |
void |
BrokerConnectorImpl.sendMessage(BrokerClient client,
ActiveMQMessage message)
Send a non-transacted message to the Broker |
void |
BrokerConnectorImpl.acknowledgeMessage(BrokerClient client,
MessageAck ack)
Acknowledge reciept of a message |
void |
BrokerConnectorImpl.durableUnsubscribe(BrokerClient client,
DurableUnsubscribe ds)
Command to delete a durable topic subscription |
void |
BrokerConnectorImpl.startTransaction(BrokerClient client,
ActiveMQXid xid)
Start an XA transaction. |
ActiveMQXid[] |
BrokerConnectorImpl.getPreparedTransactions(BrokerClient client)
Gets the prepared XA transactions. |
int |
BrokerConnectorImpl.prepareTransaction(BrokerClient client,
ActiveMQXid xid)
Prepare an XA transaction. |
void |
BrokerConnectorImpl.rollbackTransaction(BrokerClient client,
ActiveMQXid xid)
Rollback an XA transaction. |
void |
BrokerConnectorImpl.commitTransaction(BrokerClient client,
ActiveMQXid xid,
boolean onePhase)
Commit an XA transaction. |
String |
BrokerConnectorImpl.getResourceManagerId(BrokerClient client)
|
void |
DefaultBroker.addClient(BrokerClient client,
ConnectionInfo info)
|
void |
DefaultBroker.removeClient(BrokerClient client,
ConnectionInfo info)
|
void |
DefaultBroker.addMessageProducer(BrokerClient client,
ProducerInfo info)
|
void |
DefaultBroker.removeMessageProducer(BrokerClient client,
ProducerInfo info)
|
void |
DefaultBroker.addMessageConsumer(BrokerClient client,
ConsumerInfo info)
Add an active message consumer |
void |
DefaultBroker.removeMessageConsumer(BrokerClient client,
ConsumerInfo info)
remove an active message consumer |
void |
DefaultBroker.sendMessage(BrokerClient client,
ActiveMQMessage message)
send a message to the broker |
void |
DefaultBroker.acknowledgeMessage(BrokerClient client,
MessageAck ack)
Acknowledge consumption of a message by the Message Consumer |
void |
DefaultBroker.startTransaction(BrokerClient client,
String transactionId)
Start a transaction. |
void |
DefaultBroker.commitTransaction(BrokerClient client,
String transactionId)
|
void |
DefaultBroker.rollbackTransaction(BrokerClient client,
String transactionId)
rollback a transaction |
void |
DefaultBroker.startTransaction(BrokerClient client,
ActiveMQXid xid)
Starts an XA Transaction. |
int |
DefaultBroker.prepareTransaction(BrokerClient client,
ActiveMQXid xid)
Prepares an XA Transaciton. |
void |
DefaultBroker.rollbackTransaction(BrokerClient client,
ActiveMQXid xid)
Rollback an XA Transaction. |
void |
DefaultBroker.commitTransaction(BrokerClient client,
ActiveMQXid xid,
boolean onePhase)
Commit an XA Transaction. |
ActiveMQXid[] |
DefaultBroker.getPreparedTransactions(BrokerClient client)
Gets the prepared XA transactions. |
protected void |
DefaultBroker.doMessageSend(BrokerClient client,
ActiveMQMessage message)
|
protected void |
DefaultBroker.fireConsumerInfo(BrokerClient client,
ConsumerInfo info)
|
void |
BrokerContainerImpl.registerConnection(BrokerClient client,
ConnectionInfo info)
registers a new Connection |
void |
BrokerContainerImpl.deregisterConnection(BrokerClient client,
ConnectionInfo info)
un-registers a Connection |
void |
BrokerContainerImpl.registerMessageConsumer(BrokerClient client,
ConsumerInfo info)
Registers a MessageConsumer |
void |
BrokerContainerImpl.deregisterMessageConsumer(BrokerClient client,
ConsumerInfo info)
De-register a MessageConsumer from the Broker |
void |
BrokerContainerImpl.registerMessageProducer(BrokerClient client,
ProducerInfo info)
Registers a MessageProducer |
void |
BrokerContainerImpl.deregisterMessageProducer(BrokerClient client,
ProducerInfo info)
De-register a MessageProducer from the Broker |
void |
BrokerContainerImpl.registerSession(BrokerClient client,
SessionInfo info)
Register a client-side Session (used for Monitoring) |
void |
BrokerContainerImpl.deregisterSession(BrokerClient client,
SessionInfo info)
De-register a client-side Session from the Broker (used for monitoring) |
void |
BrokerContainerImpl.startTransaction(BrokerClient client,
String transactionId)
Start a transaction from the Client session |
void |
BrokerContainerImpl.rollbackTransaction(BrokerClient client,
String transactionId)
Rollback a transacton |
void |
BrokerContainerImpl.commitTransaction(BrokerClient client,
String transactionId)
Commit a transaction |
void |
BrokerContainerImpl.sendMessage(BrokerClient client,
ActiveMQMessage message)
Send a non-transacted message to the Broker |
void |
BrokerContainerImpl.acknowledgeMessage(BrokerClient client,
MessageAck ack)
Acknowledge reciept of a message |
void |
BrokerContainerImpl.durableUnsubscribe(BrokerClient client,
DurableUnsubscribe ds)
Command to delete a durable topic subscription |
void |
BrokerContainerImpl.startTransaction(BrokerClient client,
ActiveMQXid xid)
Start an XA transaction. |
ActiveMQXid[] |
BrokerContainerImpl.getPreparedTransactions(BrokerClient client)
Gets the prepared XA transactions. |
int |
BrokerContainerImpl.prepareTransaction(BrokerClient client,
ActiveMQXid xid)
Prepare an XA transaction. |
void |
BrokerContainerImpl.rollbackTransaction(BrokerClient client,
ActiveMQXid xid)
Rollback an XA transaction. |
void |
BrokerContainerImpl.commitTransaction(BrokerClient client,
ActiveMQXid xid,
boolean onePhase)
Commit an XA transaction. |
Uses of BrokerClient in org.activemq.security |
Methods in org.activemq.security with parameters of type BrokerClient | |
void |
SecurityAdapter.authorizeConnection(BrokerClient client,
ConnectionInfo info)
Authenticates the connection and authorizes it for use with this Message Broker |
void |
SecurityAdapter.authorizeConsumer(BrokerClient client,
ConsumerInfo info)
Authorizes that the consumer can start with the given consumer information |
void |
SecurityAdapter.authorizeProducer(BrokerClient client,
ProducerInfo info)
Authorizes that the prodcuer can start with the given producer information. |
void |
SecurityAdapter.authorizeSendMessage(BrokerClient client,
ActiveMQMessage message)
Authorizes on a per message basis whether or not the client is allowed to send the given message. |
boolean |
SecurityAdapter.authorizeReceive(BrokerClient client,
ActiveMQMessage message)
Returns true if the given client is authorized to receive the given message. |
Uses of BrokerClient in org.activemq.security.jassjacc |
Methods in org.activemq.security.jassjacc with parameters of type BrokerClient | |
protected AccessControlContext |
JassJaccSecurityAdapter.getAccessControlContext(BrokerClient client)
|
protected static String |
JassJaccSecurityAdapter.getBrokerName(BrokerClient client)
|
void |
JassJaccSecurityAdapter.authorizeConnection(BrokerClient client,
ConnectionInfo info)
|
void |
JassJaccSecurityAdapter.authorizeConsumer(BrokerClient client,
ConsumerInfo info)
|
boolean |
JassJaccSecurityAdapter.authorizeReceive(BrokerClient client,
ActiveMQMessage message)
|
void |
JassJaccSecurityAdapter.authorizeProducer(BrokerClient client,
ProducerInfo info)
|
void |
JassJaccSecurityAdapter.authorizeSendMessage(BrokerClient client,
ActiveMQMessage message)
|
Uses of BrokerClient in org.activemq.service |
Methods in org.activemq.service with parameters of type BrokerClient | |
void |
Dispatcher.addActiveSubscription(BrokerClient client,
Subscription sub)
Add an active subscription |
void |
Dispatcher.removeActiveSubscription(BrokerClient client,
Subscription sub)
remove an active subscription |
void |
Subscription.setActiveConsumer(BrokerClient client,
ConsumerInfo info)
Set the active consumer info |
Subscription |
SubscriptionContainer.makeSubscription(Dispatcher dispatcher,
BrokerClient client,
ConsumerInfo info,
Filter filter)
Creates a subscription (which could be a previous subscription reconecting) and adds it to this container |
void |
MessageContainerManager.addMessageConsumer(BrokerClient client,
ConsumerInfo info)
|
void |
MessageContainerManager.removeMessageConsumer(BrokerClient client,
ConsumerInfo info)
|
void |
MessageContainerManager.sendMessage(BrokerClient client,
ActiveMQMessage message)
|
void |
MessageContainerManager.acknowledgeMessage(BrokerClient client,
MessageAck ack)
Acknowledge a message as being read and consumed by the Consumer |
abstract Transaction |
TransactionManager.createLocalTransaction(BrokerClient client,
String txid)
|
abstract Transaction |
TransactionManager.createXATransaction(BrokerClient client,
ActiveMQXid xid)
|
abstract void |
TransactionManager.cleanUpClient(BrokerClient client)
A hint to the TransactionManager that an BrokerClient has stopped This enables the TransactionManager to rollback in progess transactions that the client created. |
Uses of BrokerClient in org.activemq.service.boundedvm |
Fields in org.activemq.service.boundedvm declared as BrokerClient | |
protected BrokerClient |
DurableSubscription.client
|
protected BrokerClient |
TransientSubscription.client
|
Methods in org.activemq.service.boundedvm that return BrokerClient | |
BrokerClient |
TransientTopicBoundedMessageContainer.getBrokerClient()
|
Methods in org.activemq.service.boundedvm with parameters of type BrokerClient | |
TransientQueueSubscription |
TransientQueueBoundedMessageContainer.addConsumer(Filter filter,
ConsumerInfo info,
BrokerClient client)
Add a consumer to dispatch messages to |
void |
DurableQueueBoundedMessageManager.addMessageConsumer(BrokerClient client,
ConsumerInfo info)
Add a consumer if appropiate |
void |
DurableQueueBoundedMessageManager.removeMessageConsumer(BrokerClient client,
ConsumerInfo info)
|
void |
DurableQueueBoundedMessageManager.sendMessage(BrokerClient client,
ActiveMQMessage message)
|
void |
DurableQueueBoundedMessageManager.acknowledgeMessage(BrokerClient client,
MessageAck ack)
|
void |
TransientQueueBoundedMessageManager.addMessageConsumer(BrokerClient client,
ConsumerInfo info)
Add a consumer if appropiate |
void |
TransientQueueBoundedMessageManager.removeMessageConsumer(BrokerClient client,
ConsumerInfo info)
|
void |
TransientQueueBoundedMessageManager.sendMessage(BrokerClient client,
ActiveMQMessage message)
|
void |
TransientQueueBoundedMessageManager.acknowledgeMessage(BrokerClient client,
MessageAck ack)
|
boolean |
TransientTopicBoundedMessageContainer.targetAndDispatch(BrokerClient sender,
ActiveMQMessage message)
See if this container should get this message and dispatch it |
void |
TransientTopicBoundedMessageManager.addMessageConsumer(BrokerClient client,
ConsumerInfo info)
Add a consumer if appropiate |
void |
TransientTopicBoundedMessageManager.removeMessageConsumer(BrokerClient client,
ConsumerInfo info)
|
void |
TransientTopicBoundedMessageManager.sendMessage(BrokerClient client,
ActiveMQMessage message)
|
void |
TransientTopicBoundedMessageManager.acknowledgeMessage(BrokerClient client,
MessageAck ack)
|
DurableQueueSubscription |
DurableQueueBoundedMessageContainer.addConsumer(Filter filter,
ConsumerInfo info,
BrokerClient client)
Add a consumer to dispatch messages to |
Constructors in org.activemq.service.boundedvm with parameters of type BrokerClient | |
DurableQueueSubscription(BrokerClient client,
MemoryBoundedQueue dispatchedQueue,
MemoryBoundedQueue ackQueue,
Filter filter,
ConsumerInfo info)
Construct the DurableQueueSubscription |
|
TransientTopicBoundedMessageContainer(TransientTopicBoundedMessageManager manager,
BrokerClient client,
MemoryBoundedQueue queue)
Construct this beast |
|
DurableSubscription(Filter filter,
ConsumerInfo info,
BrokerClient client)
Construct the DurableSubscription |
|
TransientQueueSubscription(BrokerClient client,
MemoryBoundedQueue dispatchedQueue,
MemoryBoundedQueue ackQueue,
Filter filter,
ConsumerInfo info)
Construct the TransientQueueSubscription |
|
TransientTopicSubscription(Filter filter,
ConsumerInfo info,
BrokerClient client)
Construct the TransientTopicSubscription |
|
TransientSubscription(Filter filter,
ConsumerInfo info,
BrokerClient client)
Construct the TransientSubscription |
Uses of BrokerClient in org.activemq.service.impl |
Methods in org.activemq.service.impl that return BrokerClient | |
BrokerClient |
SubscriptionImpl.getActiveClient()
|
Methods in org.activemq.service.impl with parameters of type BrokerClient | |
Subscription |
SubscriptionContainerImpl.makeSubscription(Dispatcher dispatcher,
BrokerClient client,
ConsumerInfo info,
Filter filter)
|
protected Subscription |
SubscriptionContainerImpl.createSubscription(Dispatcher dispatcher,
BrokerClient client,
ConsumerInfo info,
Filter filter)
|
protected void |
MessageContainerManagerSupport.updateAcknowledgeStats(BrokerClient client,
Subscription subscription)
Updates the message acknowledgement stats |
protected void |
MessageContainerManagerSupport.updateSendStats(BrokerClient client,
ActiveMQMessage message)
Updates the message sending stats |
void |
SubscriptionImpl.setActiveConsumer(BrokerClient client,
ConsumerInfo info)
Set the active consumer info |
void |
InitialImageMessageContainerManager.addMessageConsumer(BrokerClient client,
ConsumerInfo info)
|
void |
InitialImageMessageContainerManager.sendMessage(BrokerClient client,
ActiveMQMessage message)
|
protected void |
InitialImageMessageContainerManager.sendMatchingInitialImages(BrokerClient client,
ConsumerInfo info,
DestinationFilter filter)
|
void |
DurableQueueMessageContainerManager.addMessageConsumer(BrokerClient client,
ConsumerInfo info)
|
void |
DurableQueueMessageContainerManager.removeMessageConsumer(BrokerClient client,
ConsumerInfo info)
|
void |
DurableQueueMessageContainerManager.sendMessage(BrokerClient client,
ActiveMQMessage message)
|
void |
DurableQueueMessageContainerManager.acknowledgeMessage(BrokerClient client,
MessageAck ack)
Acknowledge a message as being read and consumed by the Consumer |
void |
DispatchWorker.addActiveSubscription(BrokerClient client,
Subscription sub)
Add an active subscription |
void |
DispatchWorker.removeActiveSubscription(BrokerClient client,
Subscription sub)
remove an active subscription |
void |
DispatcherImpl.addActiveSubscription(BrokerClient client,
Subscription sub)
Add an active subscription |
void |
DispatcherImpl.removeActiveSubscription(BrokerClient client,
Subscription sub)
remove an active subscription |
void |
DurableTopicMessageContainerManager.addMessageConsumer(BrokerClient client,
ConsumerInfo info)
|
void |
DurableTopicMessageContainerManager.removeMessageConsumer(BrokerClient client,
ConsumerInfo info)
|
void |
DurableTopicMessageContainerManager.sendMessage(BrokerClient client,
ActiveMQMessage message)
|
void |
DurableTopicMessageContainerManager.acknowledgeMessage(BrokerClient client,
MessageAck ack)
Acknowledge a message as being read and consumed byh the Consumer |
protected void |
DurableTopicMessageContainerManager.doAddMessageConsumer(BrokerClient client,
ConsumerInfo info)
|
Transaction |
TransactionManagerImpl.createLocalTransaction(BrokerClient client,
String txid)
|
Transaction |
TransactionManagerImpl.createXATransaction(BrokerClient client,
ActiveMQXid xid)
|
void |
TransactionManagerImpl.cleanUpClient(BrokerClient client)
|
protected Subscription |
DurableTopicSubscriptionContainerImpl.createSubscription(Dispatcher dispatcher,
BrokerClient client,
ConsumerInfo info,
Filter filter)
|
void |
TransientTopicMessageContainerManager.addMessageConsumer(BrokerClient client,
ConsumerInfo info)
|
void |
TransientTopicMessageContainerManager.removeMessageConsumer(BrokerClient client,
ConsumerInfo info)
|
void |
TransientTopicMessageContainerManager.sendMessage(BrokerClient client,
ActiveMQMessage message)
|
void |
ProxyMessageContainerManager.acknowledgeMessage(BrokerClient client,
MessageAck ack)
|
void |
ProxyMessageContainerManager.addMessageConsumer(BrokerClient client,
ConsumerInfo info)
|
void |
ProxyMessageContainerManager.removeMessageConsumer(BrokerClient client,
ConsumerInfo info)
|
void |
ProxyMessageContainerManager.sendMessage(BrokerClient client,
ActiveMQMessage message)
|
Constructors in org.activemq.service.impl with parameters of type BrokerClient | |
SubscriptionImpl(Dispatcher dispatcher,
BrokerClient client,
ConsumerInfo info,
Filter filter,
RedeliveryPolicy redeliveryPolicy,
DeadLetterPolicy deadLetterPolicy)
Create a Subscription object that holds messages to be dispatched to a Consumer |
|
DurableTopicSubscription(Dispatcher dispatcher,
BrokerClient client,
ConsumerInfo info,
Filter filter,
RedeliveryPolicy redeliveryPolicy,
DeadLetterPolicy deadLetterPolicy)
|
Uses of BrokerClient in org.activemq.transport |
Methods in org.activemq.transport with parameters of type BrokerClient | |
void |
NetworkChannel.onConsumerInfo(BrokerClient client,
ConsumerInfo info)
Listen for new Consumer events at this broker |
|
|||||||||||
PREV NEXT | FRAMES NO FRAMES |