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 BrokerService
brokerService
protected Map<ConnectionId,ConnectionState>
connectionStates
protected DestinationFactory
destinationFactory
protected DestinationStatistics
destinationStatistics
static String
ORIGINAL_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 void
acknowledge(ConsumerBrokerExchange consumerExchange, MessageAck ack)
Used to acknowledge the receipt of a message by a client.void
addBroker(Connection connection, BrokerInfo info)
A remote Broker connectsprotected void
addBrokerInClusterUpdate(BrokerInfo info)
void
addConnection(ConnectionContext context, ConnectionInfo info)
A client is establishing a connection with the broker.Subscription
addConsumer(ConnectionContext context, ConsumerInfo info)
Adds a consumer.Destination
addDestination(ConnectionContext context, ActiveMQDestination destination, boolean createIfTemp)
Used to create a destination.void
addDestinationInfo(ConnectionContext context, DestinationInfo info)
Add and process a DestinationInfo objectvoid
addProducer(ConnectionContext context, ProducerInfo info)
Adds a producer.void
beginTransaction(ConnectionContext context, TransactionId xid)
Starts a transaction.void
brokerServiceStarted()
called when the brokerService startsvoid
commitTransaction(ConnectionContext context, TransactionId xid, boolean onePhase)
Commits a transaction.protected Region
createQueueRegion(SystemUsage memoryManager, TaskRunnerFactory taskRunnerFactory, DestinationFactory destinationFactory)
protected Region
createTempQueueRegion(SystemUsage memoryManager, TaskRunnerFactory taskRunnerFactory, DestinationFactory destinationFactory)
protected Region
createTempTopicRegion(SystemUsage memoryManager, TaskRunnerFactory taskRunnerFactory, DestinationFactory destinationFactory)
protected Region
createTopicRegion(SystemUsage memoryManager, TaskRunnerFactory taskRunnerFactory, DestinationFactory destinationFactory)
protected JMSException
createUnknownDestinationTypeException(ActiveMQDestination destination)
protected void
doStop(ServiceStopper ss)
void
forgetTransaction(ConnectionContext context, TransactionId transactionId)
Forgets a transaction.void
gc()
ConnectionContext
getAdminConnectionContext()
BrokerId
getBrokerId()
Get the id of the brokerString
getBrokerName()
Get the name of the brokerlong
getBrokerSequenceId()
BrokerService
getBrokerService()
Connection[]
getClients()
ConnectionContext
getConnectionContext(String clientId)
Map<ConnectionId,ConnectionState>
getConnectionStates()
DestinationInterceptor
getDestinationInterceptor()
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 typePolicyMap
getDestinationPolicy()
ActiveMQDestination[]
getDestinations()
Set<Destination>
getDestinations(ActiveMQDestination destination)
Provide an exact or wildcard lookup of destinations in the regionDestinationStatistics
getDestinationStatistics()
Set<ActiveMQDestination>
getDurableDestinations()
ThreadPoolExecutor
getExecutor()
BrokerInfo[]
getPeerBrokerInfos()
Get the BrokerInfo's of any connected BrokersTransactionId[]
getPreparedTransactions(ConnectionContext context)
Gets a list of all the prepared xa transactions.Region
getQueueRegion()
Region
getRegion(ActiveMQDestination destination)
Broker
getRoot()
Ensure we get the Broker at the top of the StackScheduler
getScheduler()
PListStore
getTempDataStore()
Region
getTempQueueRegion()
Region
getTempTopicRegion()
Region
getTopicRegion()
URI
getVmConnectorURI()
boolean
isAllowTempAutoCreationOnSend()
protected boolean
isEqual(ConnectionId connectionId, ConnectionId connectionId2)
boolean
isExpired(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 brokerboolean
isKeepDurableSubsActive()
boolean
isStopped()
void
messageExpired(ConnectionContext context, MessageReference node, Subscription subscription)
A Message has ExpiredResponse
messagePull(ConnectionContext context, MessagePull pull)
Allows a consumer to pull a message from a queuevoid
postProcessDispatch(MessageDispatch messageDispatch)
Notify the Broker that a dispatch has happenedint
prepareTransaction(ConnectionContext context, TransactionId xid)
Prepares a transaction.void
preProcessDispatch(MessageDispatch messageDispatch)
Notify the Broker that a dispatch is going to happenvoid
processConsumerControl(ConsumerBrokerExchange consumerExchange, ConsumerControl control)
void
processDispatchNotification(MessageDispatchNotification messageDispatchNotification)
Process a notification of a dispatch - used by a Slave Brokerprotected void
purgeInactiveDestinations()
void
reapplyInterceptor()
void
removeBroker(Connection connection, BrokerInfo info)
Remove a BrokerInfoprotected void
removeBrokerInClusterUpdate(BrokerInfo info)
void
removeConnection(ConnectionContext context, ConnectionInfo info, Throwable error)
A client is disconnecting from the broker.void
removeConsumer(ConnectionContext context, ConsumerInfo info)
Removes a consumer.void
removeDestination(ConnectionContext context, ActiveMQDestination destination, long timeout)
Used to destroy a destination.void
removeDestinationInfo(ConnectionContext context, DestinationInfo info)
Remove and process a DestinationInfo objectvoid
removeProducer(ConnectionContext context, ProducerInfo info)
Removes a producer.void
removeSubscription(ConnectionContext context, RemoveSubscriptionInfo info)
Deletes a durable subscription.void
rollbackTransaction(ConnectionContext context, TransactionId xid)
Rollsback a transaction.void
send(ProducerBrokerExchange producerExchange, Message message)
Send a message to the broker to using the specified destination.boolean
sendToDeadLetterQueue(ConnectionContext context, MessageReference node, Subscription subscription, Throwable poisonCause)
A message needs to go the a DLQvoid
setAdminConnectionContext(ConnectionContext adminConnectionContext)
Sets the default administration connection context used when configuring the broker on startup or via JMXvoid
setAllowTempAutoCreationOnSend(boolean allowTempAutoCreationOnSend)
void
setBrokerId(BrokerId brokerId)
void
setBrokerName(String brokerName)
void
setKeepDurableSubsActive(boolean keepDurableSubsActive)
void
start()
void
stop()
-
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:Region
Returns a reference to the concurrent hash map that holds known destinations, do not modify- Specified by:
getDestinationMap
in interfaceRegion
- Overrides:
getDestinationMap
in classEmptyBroker
-
getDestinationMap
public Map<ActiveMQDestination,Destination> getDestinationMap(ActiveMQDestination destination)
Description copied from interface:Broker
return a reference destination map of a region based on the destination type- Specified by:
getDestinationMap
in interfaceBroker
- Overrides:
getDestinationMap
in classEmptyBroker
- Returns:
- destination Map
-
getDestinations
public Set<Destination> getDestinations(ActiveMQDestination destination)
Description copied from interface:Region
Provide an exact or wildcard lookup of destinations in the region- Specified by:
getDestinations
in interfaceRegion
- Overrides:
getDestinations
in 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:
start
in interfaceService
- Overrides:
start
in classEmptyBroker
- Throws:
Exception
-
stop
public void stop() throws Exception
- Specified by:
stop
in interfaceService
- Overrides:
stop
in 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:Broker
A client is establishing a connection with the broker.- Specified by:
addConnection
in interfaceBroker
- Overrides:
addConnection
in classEmptyBroker
- Throws:
Exception
- TODO
-
removeConnection
public void removeConnection(ConnectionContext context, ConnectionInfo info, Throwable error) throws Exception
Description copied from interface:Broker
A client is disconnecting from the broker.- Specified by:
removeConnection
in interfaceBroker
- Overrides:
removeConnection
in 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:
getClients
in interfaceBroker
- Overrides:
getClients
in 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:Region
Used 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:
addDestination
in interfaceRegion
- Overrides:
addDestination
in classEmptyBroker
destination
- 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:Region
Used 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:
removeDestination
in interfaceRegion
- Overrides:
removeDestination
in 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:Broker
Add and process a DestinationInfo object- Specified by:
addDestinationInfo
in interfaceBroker
- Overrides:
addDestinationInfo
in classEmptyBroker
- Throws:
Exception
-
removeDestinationInfo
public void removeDestinationInfo(ConnectionContext context, DestinationInfo info) throws Exception
Description copied from interface:Broker
Remove and process a DestinationInfo object- Specified by:
removeDestinationInfo
in interfaceBroker
- Overrides:
removeDestinationInfo
in classEmptyBroker
- Throws:
Exception
-
getDestinations
public ActiveMQDestination[] getDestinations() throws Exception
- Specified by:
getDestinations
in interfaceBroker
- Overrides:
getDestinations
in 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:Broker
Adds a producer.- Specified by:
addProducer
in interfaceBroker
- Specified by:
addProducer
in interfaceRegion
- Overrides:
addProducer
in 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:Broker
Removes a producer.- Specified by:
removeProducer
in interfaceBroker
- Specified by:
removeProducer
in interfaceRegion
- Overrides:
removeProducer
in 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:Region
Adds a consumer.- Specified by:
addConsumer
in interfaceRegion
- Overrides:
addConsumer
in 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:Region
Removes a consumer.- Specified by:
removeConsumer
in interfaceRegion
- Overrides:
removeConsumer
in 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:Region
Deletes a durable subscription.- Specified by:
removeSubscription
in interfaceRegion
- Overrides:
removeSubscription
in 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:Region
Send 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:
send
in interfaceRegion
- Overrides:
send
in 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:Region
Used to acknowledge the receipt of a message by a client.- Specified by:
acknowledge
in interfaceRegion
- Overrides:
acknowledge
in 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:Region
Allows a consumer to pull a message from a queue- Specified by:
messagePull
in interfaceRegion
- Overrides:
messagePull
in classEmptyBroker
- Throws:
Exception
-
getPreparedTransactions
public TransactionId[] getPreparedTransactions(ConnectionContext context) throws Exception
Description copied from interface:Broker
Gets a list of all the prepared xa transactions.- Specified by:
getPreparedTransactions
in interfaceBroker
- Overrides:
getPreparedTransactions
in 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:Broker
Starts a transaction.- Specified by:
beginTransaction
in interfaceBroker
- Overrides:
beginTransaction
in classEmptyBroker
- Throws:
Exception
- TODO
-
prepareTransaction
public int prepareTransaction(ConnectionContext context, TransactionId xid) throws Exception
Description copied from interface:Broker
Prepares a transaction. Only valid for xa transactions.- Specified by:
prepareTransaction
in interfaceBroker
- Overrides:
prepareTransaction
in classEmptyBroker
- Returns:
- id
- Throws:
Exception
- TODO
-
rollbackTransaction
public void rollbackTransaction(ConnectionContext context, TransactionId xid) throws Exception
Description copied from interface:Broker
Rollsback a transaction.- Specified by:
rollbackTransaction
in interfaceBroker
- Overrides:
rollbackTransaction
in classEmptyBroker
- Throws:
Exception
- TODO
-
commitTransaction
public void commitTransaction(ConnectionContext context, TransactionId xid, boolean onePhase) throws Exception
Description copied from interface:Broker
Commits a transaction.- Specified by:
commitTransaction
in interfaceBroker
- Overrides:
commitTransaction
in classEmptyBroker
- Throws:
Exception
- TODO
-
forgetTransaction
public void forgetTransaction(ConnectionContext context, TransactionId transactionId) throws Exception
Description copied from interface:Broker
Forgets a transaction.- Specified by:
forgetTransaction
in interfaceBroker
- Overrides:
forgetTransaction
in classEmptyBroker
- Throws:
Exception
-
gc
public void gc()
- Specified by:
gc
in interfaceRegion
- Overrides:
gc
in classEmptyBroker
-
getBrokerId
public BrokerId getBrokerId()
Description copied from interface:Broker
Get the id of the broker- Specified by:
getBrokerId
in interfaceBroker
- Overrides:
getBrokerId
in classEmptyBroker
-
setBrokerId
public void setBrokerId(BrokerId brokerId)
-
getBrokerName
public String getBrokerName()
Description copied from interface:Broker
Get the name of the broker- Specified by:
getBrokerName
in interfaceBroker
- Overrides:
getBrokerName
in 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:Broker
A remote Broker connects- Specified by:
addBroker
in interfaceBroker
- Overrides:
addBroker
in classEmptyBroker
-
removeBroker
public void removeBroker(Connection connection, BrokerInfo info)
Description copied from interface:Broker
Remove a BrokerInfo- Specified by:
removeBroker
in interfaceBroker
- Overrides:
removeBroker
in classEmptyBroker
-
getPeerBrokerInfos
public BrokerInfo[] getPeerBrokerInfos()
Description copied from interface:Broker
Get the BrokerInfo's of any connected Brokers- Specified by:
getPeerBrokerInfos
in interfaceBroker
- Overrides:
getPeerBrokerInfos
in classEmptyBroker
- Returns:
- array of peer BrokerInfos
-
preProcessDispatch
public void preProcessDispatch(MessageDispatch messageDispatch)
Description copied from interface:Broker
Notify the Broker that a dispatch is going to happen- Specified by:
preProcessDispatch
in interfaceBroker
- Overrides:
preProcessDispatch
in classEmptyBroker
-
postProcessDispatch
public void postProcessDispatch(MessageDispatch messageDispatch)
Description copied from interface:Broker
Notify the Broker that a dispatch has happened- Specified by:
postProcessDispatch
in interfaceBroker
- Overrides:
postProcessDispatch
in classEmptyBroker
-
processDispatchNotification
public void processDispatchNotification(MessageDispatchNotification messageDispatchNotification) throws Exception
Description copied from interface:Region
Process a notification of a dispatch - used by a Slave Broker- Specified by:
processDispatchNotification
in interfaceRegion
- Overrides:
processDispatchNotification
in classEmptyBroker
- Throws:
Exception
- TODO
-
isStopped
public boolean isStopped()
- Specified by:
isStopped
in interfaceBroker
- Overrides:
isStopped
in classEmptyBroker
- Returns:
- true if the broker has stopped
-
getDurableDestinations
public Set<ActiveMQDestination> getDurableDestinations()
- Specified by:
getDurableDestinations
in interfaceBroker
- Overrides:
getDurableDestinations
in 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:
getAdminConnectionContext
in interfaceBroker
- Overrides:
getAdminConnectionContext
in 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:Broker
Sets the default administration connection context used when configuring the broker on startup or via JMX- Specified by:
setAdminConnectionContext
in interfaceBroker
- Overrides:
setAdminConnectionContext
in classEmptyBroker
-
getConnectionStates
public Map<ConnectionId,ConnectionState> getConnectionStates()
-
getTempDataStore
public PListStore getTempDataStore()
- Specified by:
getTempDataStore
in interfaceBroker
- Overrides:
getTempDataStore
in classEmptyBroker
- Returns:
- the temp data store
-
getVmConnectorURI
public URI getVmConnectorURI()
- Specified by:
getVmConnectorURI
in interfaceBroker
- Overrides:
getVmConnectorURI
in classEmptyBroker
- Returns:
- the URI that can be used to connect to the local Broker
-
brokerServiceStarted
public void brokerServiceStarted()
Description copied from interface:Broker
called when the brokerService starts- Specified by:
brokerServiceStarted
in interfaceBroker
- Overrides:
brokerServiceStarted
in classEmptyBroker
-
getBrokerService
public BrokerService getBrokerService()
- Specified by:
getBrokerService
in interfaceBroker
- Overrides:
getBrokerService
in classEmptyBroker
- Returns:
- the BrokerService
-
isExpired
public boolean isExpired(MessageReference messageReference)
Description copied from interface:Broker
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 broker- Specified by:
isExpired
in interfaceBroker
- Overrides:
isExpired
in classEmptyBroker
- Returns:
- true if the message is expired
-
messageExpired
public void messageExpired(ConnectionContext context, MessageReference node, Subscription subscription)
Description copied from interface:Broker
A Message has Expired- Specified by:
messageExpired
in interfaceBroker
- Overrides:
messageExpired
in classEmptyBroker
subscription
- (may be null)
-
sendToDeadLetterQueue
public boolean sendToDeadLetterQueue(ConnectionContext context, MessageReference node, Subscription subscription, Throwable poisonCause)
Description copied from interface:Broker
A message needs to go the a DLQ- Specified by:
sendToDeadLetterQueue
in interfaceBroker
- Overrides:
sendToDeadLetterQueue
in classEmptyBroker
poisonCause
- 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:Broker
Ensure we get the Broker at the top of the Stack- Specified by:
getRoot
in interfaceBroker
- Overrides:
getRoot
in classEmptyBroker
- Returns:
- the broker at the top of the Stack
-
getBrokerSequenceId
public long getBrokerSequenceId()
- Specified by:
getBrokerSequenceId
in interfaceBroker
- Overrides:
getBrokerSequenceId
in classEmptyBroker
- Returns:
- the broker sequence id
-
getScheduler
public Scheduler getScheduler()
- Specified by:
getScheduler
in interfaceBroker
- Overrides:
getScheduler
in classEmptyBroker
-
getExecutor
public ThreadPoolExecutor getExecutor()
- Specified by:
getExecutor
in interfaceBroker
- Overrides:
getExecutor
in classEmptyBroker
-
processConsumerControl
public void processConsumerControl(ConsumerBrokerExchange consumerExchange, ConsumerControl control)
- Specified by:
processConsumerControl
in interfaceRegion
- Overrides:
processConsumerControl
in 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:
reapplyInterceptor
in interfaceRegion
- Overrides:
reapplyInterceptor
in classEmptyBroker
-
-