Package org.apache.activemq.broker
Class EmptyBroker
- java.lang.Object
-
- org.apache.activemq.broker.EmptyBroker
-
-
Constructor Summary
Constructors Constructor Description EmptyBroker()
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description voidacknowledge(ConsumerBrokerExchange consumerExchange, MessageAck ack)Used to acknowledge the receipt of a message by a client.voidaddBroker(Connection connection, BrokerInfo info)A remote Broker connectsvoidaddConnection(ConnectionContext context, ConnectionInfo info)A client is establishing a connection with the broker.SubscriptionaddConsumer(ConnectionContext context, ConsumerInfo info)Adds a consumer.DestinationaddDestination(ConnectionContext context, ActiveMQDestination destination, boolean flag)Used to create a destination.voidaddDestinationInfo(ConnectionContext context, DestinationInfo info)Add and process a DestinationInfo objectvoidaddProducer(ConnectionContext context, ProducerInfo info)Adds a producer.voidaddSession(ConnectionContext context, SessionInfo info)Adds a session.voidbeginTransaction(ConnectionContext context, TransactionId xid)Starts a transaction.voidbrokerServiceStarted()called when the brokerService startsvoidcommitTransaction(ConnectionContext context, TransactionId xid, boolean onePhase)Commits a transaction.voidfastProducer(ConnectionContext context, ProducerInfo producerInfo, ActiveMQDestination destination)Called to notify a producer is too fastvoidforgetTransaction(ConnectionContext context, TransactionId transactionId)Forgets a transaction.voidgc()BrokergetAdaptor(Class<?> type)Get a Broker from the Broker Stack that is a particular classConnectionContextgetAdminConnectionContext()BrokerIdgetBrokerId()Get the id of the brokerStringgetBrokerName()Get the name of the brokerlonggetBrokerSequenceId()BrokerServicegetBrokerService()Connection[]getClients()Map<ActiveMQDestination,Destination>getDestinationMap()Returns a reference to the concurrent hash map that holds known destinations, do not modifyMap<ActiveMQDestination,Destination>getDestinationMap(ActiveMQDestination destination)return a reference destination map of a region based on the destination typeActiveMQDestination[]getDestinations()Set<Destination>getDestinations(ActiveMQDestination destination)Provide an exact or wildcard lookup of destinations in the regionSet<ActiveMQDestination>getDurableDestinations()ThreadPoolExecutorgetExecutor()BrokerInfo[]getPeerBrokerInfos()Get the BrokerInfo's of any connected BrokersTransactionId[]getPreparedTransactions(ConnectionContext context)Gets a list of all the prepared xa transactions.BrokergetRoot()Ensure we get the Broker at the top of the StackSchedulergetScheduler()PListStoregetTempDataStore()URIgetVmConnectorURI()booleanisExpired(MessageReference messageReference)Determine if a message has expired -allows default behaviour to be overriden - as the timestamp set by the producer can be out of sync with the brokerbooleanisFaultTolerantConfiguration()voidisFull(ConnectionContext context, Destination destination, Usage<?> usage)Called when a Usage reaches a limitbooleanisStopped()voidmessageConsumed(ConnectionContext context, MessageReference messageReference)called when message is consumedvoidmessageDelivered(ConnectionContext context, MessageReference messageReference)Called when message is delivered to the brokervoidmessageDiscarded(ConnectionContext context, Subscription sub, MessageReference messageReference)Called when a message is discarded - e.g.voidmessageExpired(ConnectionContext context, MessageReference message, Subscription subscription)A Message has ExpiredResponsemessagePull(ConnectionContext context, MessagePull pull)Allows a consumer to pull a message from a queuevoidnetworkBridgeStarted(BrokerInfo brokerInfo, boolean createdByDuplex, String remoteIp)voidnetworkBridgeStopped(BrokerInfo brokerInfo)voidnowMasterBroker()called when the broker becomes the master in a master/slave configurationvoidpostProcessDispatch(MessageDispatch messageDispatch)Notify the Broker that a dispatch has happenedintprepareTransaction(ConnectionContext context, TransactionId xid)Prepares a transaction.voidpreProcessDispatch(MessageDispatch messageDispatch)Notify the Broker that a dispatch is going to happenvoidprocessConsumerControl(ConsumerBrokerExchange consumerExchange, ConsumerControl control)voidprocessDispatchNotification(MessageDispatchNotification messageDispatchNotification)Process a notification of a dispatch - used by a Slave BrokervoidreapplyInterceptor()voidremoveBroker(Connection connection, BrokerInfo info)Remove a BrokerInfovoidremoveConnection(ConnectionContext context, ConnectionInfo info, Throwable error)A client is disconnecting from the broker.voidremoveConsumer(ConnectionContext context, ConsumerInfo info)Removes a consumer.voidremoveDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)Used to destroy a destination.voidremoveDestinationInfo(ConnectionContext context, DestinationInfo info)Remove and process a DestinationInfo objectvoidremoveProducer(ConnectionContext context, ProducerInfo info)Removes a producer.voidremoveSession(ConnectionContext context, SessionInfo info)Removes a session.voidremoveSubscription(ConnectionContext context, RemoveSubscriptionInfo info)Deletes a durable subscription.voidrollbackTransaction(ConnectionContext context, TransactionId xid)Rollsback a transaction.voidsend(ProducerBrokerExchange producerExchange, Message message)Send a message to the broker to using the specified destination.booleansendToDeadLetterQueue(ConnectionContext context, MessageReference messageReference, Subscription subscription, Throwable poisonCause)A message needs to go the a DLQvoidsetAdminConnectionContext(ConnectionContext adminConnectionContext)Sets the default administration connection context used when configuring the broker on startup or via JMXvoidslowConsumer(ConnectionContext context, Destination destination, Subscription subs)Called when there is a slow consumervoidstart()voidstop()voidvirtualDestinationAdded(ConnectionContext context, VirtualDestination virtualDestination)voidvirtualDestinationRemoved(ConnectionContext context, VirtualDestination virtualDestination)
-
-
-
Method Detail
-
getBrokerId
public BrokerId getBrokerId()
Description copied from interface:BrokerGet the id of the broker- Specified by:
getBrokerIdin interfaceBroker
-
getBrokerName
public String getBrokerName()
Description copied from interface:BrokerGet the name of the broker- Specified by:
getBrokerNamein interfaceBroker
-
getAdaptor
public Broker getAdaptor(Class<?> type)
Description copied from interface:BrokerGet a Broker from the Broker Stack that is a particular class- Specified by:
getAdaptorin interfaceBroker- Returns:
- a Broker instance.
-
getDestinationMap
public Map<ActiveMQDestination,Destination> getDestinationMap()
Description copied from interface:RegionReturns a reference to the concurrent hash map that holds known destinations, do not modify- Specified by:
getDestinationMapin interfaceRegion
-
getDestinationMap
public Map<ActiveMQDestination,Destination> getDestinationMap(ActiveMQDestination destination)
Description copied from interface:Brokerreturn a reference destination map of a region based on the destination type- Specified by:
getDestinationMapin interfaceBroker- Returns:
- destination Map
-
getDestinations
public Set<Destination> getDestinations(ActiveMQDestination destination)
Description copied from interface:RegionProvide an exact or wildcard lookup of destinations in the region- Specified by:
getDestinationsin interfaceRegion- Returns:
- a set of matching destination objects.
-
addConnection
public void addConnection(ConnectionContext context, ConnectionInfo info) throws Exception
Description copied from interface:BrokerA client is establishing a connection with the broker.- Specified by:
addConnectionin interfaceBroker- Throws:
Exception- TODO
-
removeConnection
public void removeConnection(ConnectionContext context, ConnectionInfo info, Throwable error) throws Exception
Description copied from interface:BrokerA client is disconnecting from the broker.- Specified by:
removeConnectionin interfaceBroker- Parameters:
context- the environment the operation is being executed under.error- null if the client requested the disconnect or the error that caused the client to disconnect.- Throws:
Exception- TODO
-
addSession
public void addSession(ConnectionContext context, SessionInfo info) throws Exception
Description copied from interface:BrokerAdds a session.- Specified by:
addSessionin interfaceBroker- Throws:
Exception- TODO
-
removeSession
public void removeSession(ConnectionContext context, SessionInfo info) throws Exception
Description copied from interface:BrokerRemoves a session.- Specified by:
removeSessionin interfaceBroker- Throws:
Exception- TODO
-
addProducer
public void addProducer(ConnectionContext context, ProducerInfo info) throws Exception
Description copied from interface:BrokerAdds a producer.- Specified by:
addProducerin interfaceBroker- Specified by:
addProducerin interfaceRegion- Parameters:
context- the environment the operation is being executed under.- Throws:
Exception- TODO
-
removeProducer
public void removeProducer(ConnectionContext context, ProducerInfo info) throws Exception
Description copied from interface:BrokerRemoves a producer.- Specified by:
removeProducerin interfaceBroker- Specified by:
removeProducerin interfaceRegion- Parameters:
context- the environment the operation is being executed under.- Throws:
Exception- TODO
-
getClients
public Connection[] getClients() throws Exception
- Specified by:
getClientsin interfaceBroker- Returns:
- all clients added to the Broker.
- Throws:
Exception- TODO
-
getDestinations
public ActiveMQDestination[] getDestinations() throws Exception
- Specified by:
getDestinationsin interfaceBroker- Returns:
- all destinations added to the Broker.
- Throws:
Exception- TODO
-
getPreparedTransactions
public TransactionId[] getPreparedTransactions(ConnectionContext context) throws Exception
Description copied from interface:BrokerGets a list of all the prepared xa transactions.- Specified by:
getPreparedTransactionsin interfaceBroker- Parameters:
context- transaction ids- Returns:
- array of TransactionId values
- Throws:
Exception- TODO
-
beginTransaction
public void beginTransaction(ConnectionContext context, TransactionId xid) throws Exception
Description copied from interface:BrokerStarts a transaction.- Specified by:
beginTransactionin interfaceBroker- Throws:
Exception- TODO
-
prepareTransaction
public int prepareTransaction(ConnectionContext context, TransactionId xid) throws Exception
Description copied from interface:BrokerPrepares a transaction. Only valid for xa transactions.- Specified by:
prepareTransactionin interfaceBroker- Returns:
- id
- Throws:
Exception- TODO
-
rollbackTransaction
public void rollbackTransaction(ConnectionContext context, TransactionId xid) throws Exception
Description copied from interface:BrokerRollsback a transaction.- Specified by:
rollbackTransactionin interfaceBroker- Throws:
Exception- TODO
-
commitTransaction
public void commitTransaction(ConnectionContext context, TransactionId xid, boolean onePhase) throws Exception
Description copied from interface:BrokerCommits a transaction.- Specified by:
commitTransactionin interfaceBroker- Throws:
Exception- TODO
-
forgetTransaction
public void forgetTransaction(ConnectionContext context, TransactionId transactionId) throws Exception
Description copied from interface:BrokerForgets a transaction.- Specified by:
forgetTransactionin interfaceBroker- Throws:
Exception
-
addDestination
public Destination addDestination(ConnectionContext context, ActiveMQDestination destination, boolean flag) throws Exception
Description copied from interface:RegionUsed to create a destination. Usually, this method is invoked as a side-effect of sending a message to a destination that does not exist yet.- Specified by:
addDestinationin interfaceRegiondestination- the destination to create.- Returns:
- TODO
- Throws:
Exception- TODO
-
removeDestination
public void removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout) throws Exception
Description copied from interface:RegionUsed to destroy a destination. This should try to quiesce use of the destination up to the timeout allotted time before removing the destination. This will remove all persistent messages associated with the destination.- Specified by:
removeDestinationin interfaceRegion- Parameters:
context- the environment the operation is being executed under.destination- what is being removed from the broker.timeout- the max amount of time to wait for the destination to quiesce- Throws:
Exception- TODO
-
addConsumer
public Subscription addConsumer(ConnectionContext context, ConsumerInfo info) throws Exception
Description copied from interface:RegionAdds a consumer.- Specified by:
addConsumerin interfaceRegion- Parameters:
context- the environment the operation is being executed under.- Returns:
- TODO
- Throws:
Exception- TODO
-
removeConsumer
public void removeConsumer(ConnectionContext context, ConsumerInfo info) throws Exception
Description copied from interface:RegionRemoves a consumer.- Specified by:
removeConsumerin interfaceRegion- Parameters:
context- the environment the operation is being executed under.- Throws:
Exception- TODO
-
removeSubscription
public void removeSubscription(ConnectionContext context, RemoveSubscriptionInfo info) throws Exception
Description copied from interface:RegionDeletes a durable subscription.- Specified by:
removeSubscriptionin interfaceRegion- Parameters:
context- the environment the operation is being executed under.info- TODO- Throws:
Exception- TODO
-
send
public void send(ProducerBrokerExchange producerExchange, Message message) throws Exception
Description copied from interface:RegionSend a message to the broker to using the specified destination. The destination specified in the message does not need to match the destination the message is sent to. This is handy in case the message is being sent to a dead letter destination.
-
acknowledge
public void acknowledge(ConsumerBrokerExchange consumerExchange, MessageAck ack) throws Exception
Description copied from interface:RegionUsed to acknowledge the receipt of a message by a client.- Specified by:
acknowledgein interfaceRegion- Parameters:
consumerExchange- the environment the operation is being executed under.- Throws:
Exception- TODO
-
start
public void start() throws Exception
-
addBroker
public void addBroker(Connection connection, BrokerInfo info)
Description copied from interface:BrokerA remote Broker connects
-
removeBroker
public void removeBroker(Connection connection, BrokerInfo info)
Description copied from interface:BrokerRemove a BrokerInfo- Specified by:
removeBrokerin interfaceBroker
-
getPeerBrokerInfos
public BrokerInfo[] getPeerBrokerInfos()
Description copied from interface:BrokerGet the BrokerInfo's of any connected Brokers- Specified by:
getPeerBrokerInfosin interfaceBroker- Returns:
- array of peer BrokerInfos
-
preProcessDispatch
public void preProcessDispatch(MessageDispatch messageDispatch)
Description copied from interface:BrokerNotify the Broker that a dispatch is going to happen- Specified by:
preProcessDispatchin interfaceBroker
-
postProcessDispatch
public void postProcessDispatch(MessageDispatch messageDispatch)
Description copied from interface:BrokerNotify the Broker that a dispatch has happened- Specified by:
postProcessDispatchin interfaceBroker
-
processDispatchNotification
public void processDispatchNotification(MessageDispatchNotification messageDispatchNotification) throws Exception
Description copied from interface:RegionProcess a notification of a dispatch - used by a Slave Broker- Specified by:
processDispatchNotificationin interfaceRegion- Throws:
Exception- TODO
-
isStopped
public boolean isStopped()
-
getDurableDestinations
public Set<ActiveMQDestination> getDurableDestinations()
- Specified by:
getDurableDestinationsin interfaceBroker- Returns:
- a Set of all durable destinations
-
addDestinationInfo
public void addDestinationInfo(ConnectionContext context, DestinationInfo info) throws Exception
Description copied from interface:BrokerAdd and process a DestinationInfo object- Specified by:
addDestinationInfoin interfaceBroker- Throws:
Exception
-
removeDestinationInfo
public void removeDestinationInfo(ConnectionContext context, DestinationInfo info) throws Exception
Description copied from interface:BrokerRemove and process a DestinationInfo object- Specified by:
removeDestinationInfoin interfaceBroker- Throws:
Exception
-
isFaultTolerantConfiguration
public boolean isFaultTolerantConfiguration()
- Specified by:
isFaultTolerantConfigurationin interfaceBroker- Returns:
- true if fault tolerant
-
getAdminConnectionContext
public ConnectionContext getAdminConnectionContext()
- Specified by:
getAdminConnectionContextin interfaceBroker- Returns:
- the connection context used to make administration operations on startup or via JMX MBeans
-
setAdminConnectionContext
public void setAdminConnectionContext(ConnectionContext adminConnectionContext)
Description copied from interface:BrokerSets the default administration connection context used when configuring the broker on startup or via JMX- Specified by:
setAdminConnectionContextin interfaceBroker
-
messagePull
public Response messagePull(ConnectionContext context, MessagePull pull) throws Exception
Description copied from interface:RegionAllows a consumer to pull a message from a queue- Specified by:
messagePullin interfaceRegion- Throws:
Exception
-
getTempDataStore
public PListStore getTempDataStore()
- Specified by:
getTempDataStorein interfaceBroker- Returns:
- the temp data store
-
getVmConnectorURI
public URI getVmConnectorURI()
- Specified by:
getVmConnectorURIin interfaceBroker- Returns:
- the URI that can be used to connect to the local Broker
-
brokerServiceStarted
public void brokerServiceStarted()
Description copied from interface:Brokercalled when the brokerService starts- Specified by:
brokerServiceStartedin interfaceBroker
-
getBrokerService
public BrokerService getBrokerService()
- Specified by:
getBrokerServicein interfaceBroker- Returns:
- the BrokerService
-
isExpired
public boolean isExpired(MessageReference messageReference)
Description copied from interface:BrokerDetermine if a message has expired -allows default behaviour to be overriden - as the timestamp set by the producer can be out of sync with the broker
-
messageExpired
public void messageExpired(ConnectionContext context, MessageReference message, Subscription subscription)
Description copied from interface:BrokerA Message has Expired- Specified by:
messageExpiredin interfaceBrokersubscription- (may be null)
-
sendToDeadLetterQueue
public boolean sendToDeadLetterQueue(ConnectionContext context, MessageReference messageReference, Subscription subscription, Throwable poisonCause)
Description copied from interface:BrokerA message needs to go the a DLQ- Specified by:
sendToDeadLetterQueuein interfaceBrokerpoisonCause- reason for dlq submission, may be null- Returns:
- true if Message was placed in a DLQ false if discarded.
-
getRoot
public Broker getRoot()
Description copied from interface:BrokerEnsure we get the Broker at the top of the Stack
-
getBrokerSequenceId
public long getBrokerSequenceId()
- Specified by:
getBrokerSequenceIdin interfaceBroker- Returns:
- the broker sequence id
-
fastProducer
public void fastProducer(ConnectionContext context, ProducerInfo producerInfo, ActiveMQDestination destination)
Description copied from interface:BrokerCalled to notify a producer is too fast- Specified by:
fastProducerin interfaceBroker
-
isFull
public void isFull(ConnectionContext context, Destination destination, Usage<?> usage)
Description copied from interface:BrokerCalled when a Usage reaches a limit
-
messageConsumed
public void messageConsumed(ConnectionContext context, MessageReference messageReference)
Description copied from interface:Brokercalled when message is consumed- Specified by:
messageConsumedin interfaceBroker
-
messageDelivered
public void messageDelivered(ConnectionContext context, MessageReference messageReference)
Description copied from interface:BrokerCalled when message is delivered to the broker- Specified by:
messageDeliveredin interfaceBroker
-
messageDiscarded
public void messageDiscarded(ConnectionContext context, Subscription sub, MessageReference messageReference)
Description copied from interface:BrokerCalled when a message is discarded - e.g. running low on memory This will happen only if the policy is enabled - e.g. non durable topics- Specified by:
messageDiscardedin interfaceBroker
-
slowConsumer
public void slowConsumer(ConnectionContext context, Destination destination, Subscription subs)
Description copied from interface:BrokerCalled when there is a slow consumer- Specified by:
slowConsumerin interfaceBroker
-
virtualDestinationAdded
public void virtualDestinationAdded(ConnectionContext context, VirtualDestination virtualDestination)
- Specified by:
virtualDestinationAddedin interfaceBroker
-
virtualDestinationRemoved
public void virtualDestinationRemoved(ConnectionContext context, VirtualDestination virtualDestination)
- Specified by:
virtualDestinationRemovedin interfaceBroker
-
nowMasterBroker
public void nowMasterBroker()
Description copied from interface:Brokercalled when the broker becomes the master in a master/slave configuration- Specified by:
nowMasterBrokerin interfaceBroker
-
networkBridgeStarted
public void networkBridgeStarted(BrokerInfo brokerInfo, boolean createdByDuplex, String remoteIp)
- Specified by:
networkBridgeStartedin interfaceBroker
-
networkBridgeStopped
public void networkBridgeStopped(BrokerInfo brokerInfo)
- Specified by:
networkBridgeStoppedin interfaceBroker
-
processConsumerControl
public void processConsumerControl(ConsumerBrokerExchange consumerExchange, ConsumerControl control)
- Specified by:
processConsumerControlin interfaceRegion
-
reapplyInterceptor
public void reapplyInterceptor()
- Specified by:
reapplyInterceptorin interfaceRegion
-
getScheduler
public Scheduler getScheduler()
- Specified by:
getSchedulerin interfaceBroker
-
getExecutor
public ThreadPoolExecutor getExecutor()
- Specified by:
getExecutorin interfaceBroker
-
-