Class RegionBroker
- java.lang.Object
-
- org.apache.activemq.broker.EmptyBroker
-
- org.apache.activemq.broker.region.RegionBroker
-
- Direct Known Subclasses:
ManagedRegionBroker
public class RegionBroker extends EmptyBroker
Routes Broker operations to the correct messaging regions for processing.
-
-
Field Summary
Fields Modifier and Type Field Description protected BrokerServicebrokerServiceprotected Map<ConnectionId,ConnectionState>connectionStatesprotected DestinationFactorydestinationFactoryprotected DestinationStatisticsdestinationStatisticsstatic StringORIGINAL_EXPIRATION
-
Constructor Summary
Constructors Constructor Description RegionBroker(BrokerService brokerService, TaskRunnerFactory taskRunnerFactory, SystemUsage memoryManager, DestinationFactory destinationFactory, DestinationInterceptor destinationInterceptor, Scheduler scheduler, ThreadPoolExecutor executor)
-
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 connectsprotected voidaddBrokerInClusterUpdate(BrokerInfo info)voidaddConnection(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 createIfTemp)Used to create a destination.voidaddDestinationInfo(ConnectionContext context, DestinationInfo info)Add and process a DestinationInfo objectvoidaddProducer(ConnectionContext context, ProducerInfo info)Adds a producer.voidbeginTransaction(ConnectionContext context, TransactionId xid)Starts a transaction.voidbrokerServiceStarted()called when the brokerService startsvoidcommitTransaction(ConnectionContext context, TransactionId xid, boolean onePhase)Commits a transaction.protected RegioncreateQueueRegion(SystemUsage memoryManager, TaskRunnerFactory taskRunnerFactory, DestinationFactory destinationFactory)protected RegioncreateTempQueueRegion(SystemUsage memoryManager, TaskRunnerFactory taskRunnerFactory, DestinationFactory destinationFactory)protected RegioncreateTempTopicRegion(SystemUsage memoryManager, TaskRunnerFactory taskRunnerFactory, DestinationFactory destinationFactory)protected RegioncreateTopicRegion(SystemUsage memoryManager, TaskRunnerFactory taskRunnerFactory, DestinationFactory destinationFactory)protected JMSExceptioncreateUnknownDestinationTypeException(ActiveMQDestination destination)protected voiddoStop(ServiceStopper ss)voidforgetTransaction(ConnectionContext context, TransactionId transactionId)Forgets a transaction.voidgc()ConnectionContextgetAdminConnectionContext()BrokerIdgetBrokerId()Get the id of the brokerStringgetBrokerName()Get the name of the brokerlonggetBrokerSequenceId()BrokerServicegetBrokerService()Connection[]getClients()ConnectionContextgetConnectionContext(String clientId)Map<ConnectionId,ConnectionState>getConnectionStates()DestinationInterceptorgetDestinationInterceptor()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 typePolicyMapgetDestinationPolicy()ActiveMQDestination[]getDestinations()Set<Destination>getDestinations(ActiveMQDestination destination)Provide an exact or wildcard lookup of destinations in the regionDestinationStatisticsgetDestinationStatistics()Set<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.RegiongetQueueRegion()RegiongetRegion(ActiveMQDestination destination)BrokergetRoot()Ensure we get the Broker at the top of the StackSchedulergetScheduler()PListStoregetTempDataStore()RegiongetTempQueueRegion()RegiongetTempTopicRegion()RegiongetTopicRegion()URIgetVmConnectorURI()booleanisAllowTempAutoCreationOnSend()protected booleanisEqual(ConnectionId connectionId, ConnectionId connectionId2)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 brokerbooleanisKeepDurableSubsActive()booleanisStopped()voidmessageExpired(ConnectionContext context, MessageReference node, Subscription subscription)A Message has ExpiredResponsemessagePull(ConnectionContext context, MessagePull pull)Allows a consumer to pull a message from a queuevoidpostProcessDispatch(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 Brokerprotected voidpurgeInactiveDestinations()voidreapplyInterceptor()voidremoveBroker(Connection connection, BrokerInfo info)Remove a BrokerInfoprotected voidremoveBrokerInClusterUpdate(BrokerInfo info)voidremoveConnection(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.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 node, 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 JMXvoidsetAllowTempAutoCreationOnSend(boolean allowTempAutoCreationOnSend)voidsetBrokerId(BrokerId brokerId)voidsetBrokerName(String brokerName)voidsetKeepDurableSubsActive(boolean keepDurableSubsActive)voidstart()voidstop()-
Methods inherited from class org.apache.activemq.broker.EmptyBroker
addSession, fastProducer, getAdaptor, isFaultTolerantConfiguration, isFull, messageConsumed, messageDelivered, messageDiscarded, networkBridgeStarted, networkBridgeStopped, nowMasterBroker, removeSession, slowConsumer, virtualDestinationAdded, virtualDestinationRemoved
-
-
-
-
Field Detail
-
ORIGINAL_EXPIRATION
public static final String ORIGINAL_EXPIRATION
- See Also:
- Constant Field Values
-
destinationStatistics
protected final DestinationStatistics destinationStatistics
-
destinationFactory
protected DestinationFactory destinationFactory
-
connectionStates
protected final Map<ConnectionId,ConnectionState> connectionStates
-
brokerService
protected final BrokerService brokerService
-
-
Constructor Detail
-
RegionBroker
public RegionBroker(BrokerService brokerService, TaskRunnerFactory taskRunnerFactory, SystemUsage memoryManager, DestinationFactory destinationFactory, DestinationInterceptor destinationInterceptor, Scheduler scheduler, ThreadPoolExecutor executor) throws IOException
- Throws:
IOException
-
-
Method Detail
-
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- Overrides:
getDestinationMapin classEmptyBroker
-
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- Overrides:
getDestinationMapin classEmptyBroker- 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- Overrides:
getDestinationsin classEmptyBroker- Returns:
- a set of matching destination objects.
-
getQueueRegion
public Region getQueueRegion()
-
getTempQueueRegion
public Region getTempQueueRegion()
-
getTempTopicRegion
public Region getTempTopicRegion()
-
getTopicRegion
public Region getTopicRegion()
-
createTempTopicRegion
protected Region createTempTopicRegion(SystemUsage memoryManager, TaskRunnerFactory taskRunnerFactory, DestinationFactory destinationFactory)
-
createTempQueueRegion
protected Region createTempQueueRegion(SystemUsage memoryManager, TaskRunnerFactory taskRunnerFactory, DestinationFactory destinationFactory)
-
createTopicRegion
protected Region createTopicRegion(SystemUsage memoryManager, TaskRunnerFactory taskRunnerFactory, DestinationFactory destinationFactory)
-
createQueueRegion
protected Region createQueueRegion(SystemUsage memoryManager, TaskRunnerFactory taskRunnerFactory, DestinationFactory destinationFactory)
-
start
public void start() throws Exception- Specified by:
startin interfaceService- Overrides:
startin classEmptyBroker- Throws:
Exception
-
stop
public void stop() throws Exception- Specified by:
stopin interfaceService- Overrides:
stopin classEmptyBroker- Throws:
Exception
-
getDestinationPolicy
public PolicyMap getDestinationPolicy()
-
getConnectionContext
public ConnectionContext getConnectionContext(String clientId)
-
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- Overrides:
addConnectionin classEmptyBroker- 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- Overrides:
removeConnectionin classEmptyBroker- 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
-
isEqual
protected boolean isEqual(ConnectionId connectionId, ConnectionId connectionId2)
-
getClients
public Connection[] getClients() throws Exception
- Specified by:
getClientsin interfaceBroker- Overrides:
getClientsin classEmptyBroker- Returns:
- all clients added to the Broker.
- Throws:
Exception- TODO
-
addDestination
public Destination addDestination(ConnectionContext context, ActiveMQDestination destination, boolean createIfTemp) 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 interfaceRegion- Overrides:
addDestinationin classEmptyBrokerdestination- 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- Overrides:
removeDestinationin classEmptyBroker- 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
-
addDestinationInfo
public void addDestinationInfo(ConnectionContext context, DestinationInfo info) throws Exception
Description copied from interface:BrokerAdd and process a DestinationInfo object- Specified by:
addDestinationInfoin interfaceBroker- Overrides:
addDestinationInfoin classEmptyBroker- 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- Overrides:
removeDestinationInfoin classEmptyBroker- Throws:
Exception
-
getDestinations
public ActiveMQDestination[] getDestinations() throws Exception
- Specified by:
getDestinationsin interfaceBroker- Overrides:
getDestinationsin classEmptyBroker- Returns:
- all destinations added to the Broker.
- 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- Overrides:
addProducerin classEmptyBroker- 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- Overrides:
removeProducerin classEmptyBroker- Parameters:
context- the environment the operation is being executed under.- Throws:
Exception- TODO
-
addConsumer
public Subscription addConsumer(ConnectionContext context, ConsumerInfo info) throws Exception
Description copied from interface:RegionAdds a consumer.- Specified by:
addConsumerin interfaceRegion- Overrides:
addConsumerin classEmptyBroker- 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- Overrides:
removeConsumerin classEmptyBroker- 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- Overrides:
removeSubscriptionin classEmptyBroker- 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.- Specified by:
sendin interfaceRegion- Overrides:
sendin classEmptyBroker- Parameters:
producerExchange- the environment the operation is being executed under.- Throws:
Exception- TODO
-
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- Overrides:
acknowledgein classEmptyBroker- Parameters:
consumerExchange- the environment the operation is being executed under.- Throws:
Exception- TODO
-
getRegion
public Region getRegion(ActiveMQDestination destination) throws JMSException
- Throws:
JMSException
-
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- Overrides:
messagePullin classEmptyBroker- Throws:
Exception
-
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- Overrides:
getPreparedTransactionsin classEmptyBroker- 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- Overrides:
beginTransactionin classEmptyBroker- 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- Overrides:
prepareTransactionin classEmptyBroker- 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- Overrides:
rollbackTransactionin classEmptyBroker- 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- Overrides:
commitTransactionin classEmptyBroker- Throws:
Exception- TODO
-
forgetTransaction
public void forgetTransaction(ConnectionContext context, TransactionId transactionId) throws Exception
Description copied from interface:BrokerForgets a transaction.- Specified by:
forgetTransactionin interfaceBroker- Overrides:
forgetTransactionin classEmptyBroker- Throws:
Exception
-
gc
public void gc()
- Specified by:
gcin interfaceRegion- Overrides:
gcin classEmptyBroker
-
getBrokerId
public BrokerId getBrokerId()
Description copied from interface:BrokerGet the id of the broker- Specified by:
getBrokerIdin interfaceBroker- Overrides:
getBrokerIdin classEmptyBroker
-
setBrokerId
public void setBrokerId(BrokerId brokerId)
-
getBrokerName
public String getBrokerName()
Description copied from interface:BrokerGet the name of the broker- Specified by:
getBrokerNamein interfaceBroker- Overrides:
getBrokerNamein classEmptyBroker
-
setBrokerName
public void setBrokerName(String brokerName)
-
getDestinationStatistics
public DestinationStatistics getDestinationStatistics()
-
createUnknownDestinationTypeException
protected JMSException createUnknownDestinationTypeException(ActiveMQDestination destination)
-
addBroker
public void addBroker(Connection connection, BrokerInfo info)
Description copied from interface:BrokerA remote Broker connects- Specified by:
addBrokerin interfaceBroker- Overrides:
addBrokerin classEmptyBroker
-
removeBroker
public void removeBroker(Connection connection, BrokerInfo info)
Description copied from interface:BrokerRemove a BrokerInfo- Specified by:
removeBrokerin interfaceBroker- Overrides:
removeBrokerin classEmptyBroker
-
getPeerBrokerInfos
public BrokerInfo[] getPeerBrokerInfos()
Description copied from interface:BrokerGet the BrokerInfo's of any connected Brokers- Specified by:
getPeerBrokerInfosin interfaceBroker- Overrides:
getPeerBrokerInfosin classEmptyBroker- 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- Overrides:
preProcessDispatchin classEmptyBroker
-
postProcessDispatch
public void postProcessDispatch(MessageDispatch messageDispatch)
Description copied from interface:BrokerNotify the Broker that a dispatch has happened- Specified by:
postProcessDispatchin interfaceBroker- Overrides:
postProcessDispatchin classEmptyBroker
-
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- Overrides:
processDispatchNotificationin classEmptyBroker- Throws:
Exception- TODO
-
isStopped
public boolean isStopped()
- Specified by:
isStoppedin interfaceBroker- Overrides:
isStoppedin classEmptyBroker- Returns:
- true if the broker has stopped
-
getDurableDestinations
public Set<ActiveMQDestination> getDurableDestinations()
- Specified by:
getDurableDestinationsin interfaceBroker- Overrides:
getDurableDestinationsin classEmptyBroker- Returns:
- a Set of all durable destinations
-
doStop
protected void doStop(ServiceStopper ss)
-
isKeepDurableSubsActive
public boolean isKeepDurableSubsActive()
-
setKeepDurableSubsActive
public void setKeepDurableSubsActive(boolean keepDurableSubsActive)
-
getDestinationInterceptor
public DestinationInterceptor getDestinationInterceptor()
-
getAdminConnectionContext
public ConnectionContext getAdminConnectionContext()
- Specified by:
getAdminConnectionContextin interfaceBroker- Overrides:
getAdminConnectionContextin classEmptyBroker- 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- Overrides:
setAdminConnectionContextin classEmptyBroker
-
getConnectionStates
public Map<ConnectionId,ConnectionState> getConnectionStates()
-
getTempDataStore
public PListStore getTempDataStore()
- Specified by:
getTempDataStorein interfaceBroker- Overrides:
getTempDataStorein classEmptyBroker- Returns:
- the temp data store
-
getVmConnectorURI
public URI getVmConnectorURI()
- Specified by:
getVmConnectorURIin interfaceBroker- Overrides:
getVmConnectorURIin classEmptyBroker- 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- Overrides:
brokerServiceStartedin classEmptyBroker
-
getBrokerService
public BrokerService getBrokerService()
- Specified by:
getBrokerServicein interfaceBroker- Overrides:
getBrokerServicein classEmptyBroker- 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- Specified by:
isExpiredin interfaceBroker- Overrides:
isExpiredin classEmptyBroker- Returns:
- true if the message is expired
-
messageExpired
public void messageExpired(ConnectionContext context, MessageReference node, Subscription subscription)
Description copied from interface:BrokerA Message has Expired- Specified by:
messageExpiredin interfaceBroker- Overrides:
messageExpiredin classEmptyBrokersubscription- (may be null)
-
sendToDeadLetterQueue
public boolean sendToDeadLetterQueue(ConnectionContext context, MessageReference node, Subscription subscription, Throwable poisonCause)
Description copied from interface:BrokerA message needs to go the a DLQ- Specified by:
sendToDeadLetterQueuein interfaceBroker- Overrides:
sendToDeadLetterQueuein classEmptyBrokerpoisonCause- 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- Specified by:
getRootin interfaceBroker- Overrides:
getRootin classEmptyBroker- Returns:
- the broker at the top of the Stack
-
getBrokerSequenceId
public long getBrokerSequenceId()
- Specified by:
getBrokerSequenceIdin interfaceBroker- Overrides:
getBrokerSequenceIdin classEmptyBroker- Returns:
- the broker sequence id
-
getScheduler
public Scheduler getScheduler()
- Specified by:
getSchedulerin interfaceBroker- Overrides:
getSchedulerin classEmptyBroker
-
getExecutor
public ThreadPoolExecutor getExecutor()
- Specified by:
getExecutorin interfaceBroker- Overrides:
getExecutorin classEmptyBroker
-
processConsumerControl
public void processConsumerControl(ConsumerBrokerExchange consumerExchange, ConsumerControl control)
- Specified by:
processConsumerControlin interfaceRegion- Overrides:
processConsumerControlin classEmptyBroker
-
addBrokerInClusterUpdate
protected void addBrokerInClusterUpdate(BrokerInfo info)
-
removeBrokerInClusterUpdate
protected void removeBrokerInClusterUpdate(BrokerInfo info)
-
purgeInactiveDestinations
protected void purgeInactiveDestinations()
-
isAllowTempAutoCreationOnSend
public boolean isAllowTempAutoCreationOnSend()
-
setAllowTempAutoCreationOnSend
public void setAllowTempAutoCreationOnSend(boolean allowTempAutoCreationOnSend)
-
reapplyInterceptor
public void reapplyInterceptor()
- Specified by:
reapplyInterceptorin interfaceRegion- Overrides:
reapplyInterceptorin classEmptyBroker
-
-