Package org.apache.activemq.broker.util
Class LoggingBrokerPlugin
- java.lang.Object
-
- org.apache.activemq.broker.BrokerFilter
-
- org.apache.activemq.broker.MutableBrokerFilter
-
- org.apache.activemq.broker.BrokerPluginSupport
-
- org.apache.activemq.broker.util.LoggingBrokerPlugin
-
- All Implemented Interfaces:
Broker,BrokerPlugin,Region,Service
public class LoggingBrokerPlugin extends BrokerPluginSupport
A simple Broker intercepter which allows you to enable/disable logging.
-
-
Field Summary
-
Fields inherited from class org.apache.activemq.broker.MutableBrokerFilter
next
-
-
Constructor Summary
Constructors Constructor Description LoggingBrokerPlugin()
-
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 create)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.voidafterPropertiesSet()voidbeginTransaction(ConnectionContext context, TransactionId xid)Starts a transaction.voidcommitTransaction(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.Connection[]getClients()ActiveMQDestination[]getDestinations()Set<ActiveMQDestination>getDurableDestinations()BrokerInfo[]getPeerBrokerInfos()Get the BrokerInfo's of any connected BrokersTransactionId[]getPreparedTransactions(ConnectionContext context)Gets a list of all the prepared xa transactions.voidisFull(ConnectionContext context, Destination destination, Usage<?> usage)Called when a Usage reaches a limitbooleanisLogAll()booleanisLogConnectionEvents()booleanisLogConsumerEvents()booleanisLogInternalEvents()booleanisLogProducerEvents()booleanisLogSessionEvents()booleanisLogTransactionEvents()booleanisPerDestinationLogger()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 queuevoidnowMasterBroker()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 happenvoidprocessDispatchNotification(MessageDispatchNotification messageDispatchNotification)Process a notification of a dispatch - used by a Slave BrokervoidremoveBroker(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 messageSend)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 DLQvoidsetLogAll(boolean logAll)Logger all Events that go through the PluginvoidsetLogConnectionEvents(boolean logConnectionEvents)Logger Events that are related to connectionsvoidsetLogConsumerEvents(boolean logConsumerEvents)Logger Events that are related to ConsumersvoidsetLogInternalEvents(boolean logInternalEvents)Logger Events that are normally internal to the brokervoidsetLogProducerEvents(boolean logProducerEvents)Logger Events that are related to ProducersvoidsetLogSessionEvents(boolean logSessionEvents)Logger Events that are related to sessionsvoidsetLogTransactionEvents(boolean logTransactionEvents)Logger Events that are related to transaction processingvoidsetPerDestinationLogger(boolean perDestinationLogger)voidslowConsumer(ConnectionContext context, Destination destination, Subscription subs)Called when there is a slow consumervoidstart()voidstop()StringtoString()-
Methods inherited from class org.apache.activemq.broker.BrokerPluginSupport
installPlugin
-
Methods inherited from class org.apache.activemq.broker.MutableBrokerFilter
getAdaptor, getNext, setNext
-
Methods inherited from class org.apache.activemq.broker.BrokerFilter
brokerServiceStarted, gc, getAdminConnectionContext, getBrokerId, getBrokerName, getBrokerSequenceId, getBrokerService, getDestinationMap, getDestinationMap, getDestinations, getExecutor, getRoot, getScheduler, getTempDataStore, getVmConnectorURI, isExpired, isFaultTolerantConfiguration, isStopped, networkBridgeStarted, networkBridgeStopped, processConsumerControl, reapplyInterceptor, setAdminConnectionContext, virtualDestinationAdded, virtualDestinationRemoved
-
-
-
-
Method Detail
-
isLogAll
public boolean isLogAll()
-
setLogAll
public void setLogAll(boolean logAll)
Logger all Events that go through the Plugin
-
isLogConnectionEvents
public boolean isLogConnectionEvents()
-
setLogConnectionEvents
public void setLogConnectionEvents(boolean logConnectionEvents)
Logger Events that are related to connections
-
isLogSessionEvents
public boolean isLogSessionEvents()
-
setLogSessionEvents
public void setLogSessionEvents(boolean logSessionEvents)
Logger Events that are related to sessions
-
isLogTransactionEvents
public boolean isLogTransactionEvents()
-
setLogTransactionEvents
public void setLogTransactionEvents(boolean logTransactionEvents)
Logger Events that are related to transaction processing
-
isLogConsumerEvents
public boolean isLogConsumerEvents()
-
setLogConsumerEvents
public void setLogConsumerEvents(boolean logConsumerEvents)
Logger Events that are related to Consumers
-
isLogProducerEvents
public boolean isLogProducerEvents()
-
setLogProducerEvents
public void setLogProducerEvents(boolean logProducerEvents)
Logger Events that are related to Producers
-
isLogInternalEvents
public boolean isLogInternalEvents()
-
setLogInternalEvents
public void setLogInternalEvents(boolean logInternalEvents)
Logger Events that are normally internal to the broker
-
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 classBrokerFilter- Parameters:
consumerExchange- the environment the operation is being executed under.- Throws:
Exception- TODO
-
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 classBrokerFilter- Throws:
Exception
-
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 classBrokerFilter- 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 classBrokerFilter- Parameters:
context- the environment the operation is being executed under.- Returns:
- TODO
- 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 classBrokerFilter- Parameters:
context- the environment the operation is being executed under.- 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 classBrokerFilter- 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 classBrokerFilter- Parameters:
context- the environment the operation is being executed under.info- TODO- 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- Overrides:
getPreparedTransactionsin classBrokerFilter- Parameters:
context- transaction ids- Returns:
- array of TransactionId values
- 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 classBrokerFilter- Returns:
- id
- 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 classBrokerFilter- 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
-
removeConsumer
public void removeConsumer(ConnectionContext context, ConsumerInfo info) throws Exception
Description copied from interface:RegionRemoves a consumer.- Specified by:
removeConsumerin interfaceRegion- Overrides:
removeConsumerin classBrokerFilter- 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 classBrokerFilter- Parameters:
context- the environment the operation is being executed under.- 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 classBrokerFilter- Throws:
Exception- TODO
-
send
public void send(ProducerBrokerExchange producerExchange, Message messageSend) 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 classBrokerFilter- Parameters:
producerExchange- the environment the operation is being executed under.- 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 classBrokerFilter- 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 classBrokerFilter- Throws:
Exception
-
getClients
public Connection[] getClients() throws Exception
- Specified by:
getClientsin interfaceBroker- Overrides:
getClientsin classBrokerFilter- Returns:
- all clients added to the Broker.
- Throws:
Exception- TODO
-
addDestination
public Destination addDestination(ConnectionContext context, ActiveMQDestination destination, boolean create) 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 classBrokerFilterdestination- 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 classBrokerFilter- 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
-
getDestinations
public ActiveMQDestination[] getDestinations() throws Exception
- Specified by:
getDestinationsin interfaceBroker- Overrides:
getDestinationsin classBrokerFilter- Returns:
- all destinations added to the Broker.
- Throws:
Exception- TODO
-
start
public void start() throws Exception- Specified by:
startin interfaceService- Overrides:
startin classBrokerPluginSupport- Throws:
Exception
-
stop
public void stop() throws Exception- Specified by:
stopin interfaceService- Overrides:
stopin classBrokerPluginSupport- Throws:
Exception
-
addSession
public void addSession(ConnectionContext context, SessionInfo info) throws Exception
Description copied from interface:BrokerAdds a session.- Specified by:
addSessionin interfaceBroker- Overrides:
addSessionin classBrokerFilter- Throws:
Exception- TODO
-
removeSession
public void removeSession(ConnectionContext context, SessionInfo info) throws Exception
Description copied from interface:BrokerRemoves a session.- Specified by:
removeSessionin interfaceBroker- Overrides:
removeSessionin classBrokerFilter- Throws:
Exception- TODO
-
addBroker
public void addBroker(Connection connection, BrokerInfo info)
Description copied from interface:BrokerA remote Broker connects- Specified by:
addBrokerin interfaceBroker- Overrides:
addBrokerin classBrokerFilter
-
removeBroker
public void removeBroker(Connection connection, BrokerInfo info)
Description copied from interface:BrokerRemove a BrokerInfo- Specified by:
removeBrokerin interfaceBroker- Overrides:
removeBrokerin classBrokerFilter
-
getPeerBrokerInfos
public BrokerInfo[] getPeerBrokerInfos()
Description copied from interface:BrokerGet the BrokerInfo's of any connected Brokers- Specified by:
getPeerBrokerInfosin interfaceBroker- Overrides:
getPeerBrokerInfosin classBrokerFilter- 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 classBrokerFilter
-
postProcessDispatch
public void postProcessDispatch(MessageDispatch messageDispatch)
Description copied from interface:BrokerNotify the Broker that a dispatch has happened- Specified by:
postProcessDispatchin interfaceBroker- Overrides:
postProcessDispatchin classBrokerFilter
-
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 classBrokerFilter- Throws:
Exception- TODO
-
getDurableDestinations
public Set<ActiveMQDestination> getDurableDestinations()
- Specified by:
getDurableDestinationsin interfaceBroker- Overrides:
getDurableDestinationsin classBrokerFilter- 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- Overrides:
addDestinationInfoin classBrokerFilter- 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 classBrokerFilter- Throws:
Exception
-
messageExpired
public void messageExpired(ConnectionContext context, MessageReference message, Subscription subscription)
Description copied from interface:BrokerA Message has Expired- Specified by:
messageExpiredin interfaceBroker- Overrides:
messageExpiredin classBrokerFiltersubscription- (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 interfaceBroker- Overrides:
sendToDeadLetterQueuein classBrokerFilterpoisonCause- reason for dlq submission, may be null- Returns:
- true if Message was placed in a DLQ false if discarded.
-
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- Overrides:
fastProducerin classBrokerFilter
-
isFull
public void isFull(ConnectionContext context, Destination destination, Usage<?> usage)
Description copied from interface:BrokerCalled when a Usage reaches a limit- Specified by:
isFullin interfaceBroker- Overrides:
isFullin classBrokerFilter
-
messageConsumed
public void messageConsumed(ConnectionContext context, MessageReference messageReference)
Description copied from interface:Brokercalled when message is consumed- Specified by:
messageConsumedin interfaceBroker- Overrides:
messageConsumedin classBrokerFilter
-
messageDelivered
public void messageDelivered(ConnectionContext context, MessageReference messageReference)
Description copied from interface:BrokerCalled when message is delivered to the broker- Specified by:
messageDeliveredin interfaceBroker- Overrides:
messageDeliveredin classBrokerFilter
-
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- Overrides:
messageDiscardedin classBrokerFilter
-
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- Overrides:
slowConsumerin classBrokerFilter
-
nowMasterBroker
public void nowMasterBroker()
Description copied from interface:Brokercalled when the broker becomes the master in a master/slave configuration- Specified by:
nowMasterBrokerin interfaceBroker- Overrides:
nowMasterBrokerin classBrokerFilter
-
setPerDestinationLogger
public void setPerDestinationLogger(boolean perDestinationLogger)
-
isPerDestinationLogger
public boolean isPerDestinationLogger()
-
-