You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@activemq.apache.org by cl...@apache.org on 2022/07/21 15:58:43 UTC

[activemq-artemis] branch new-logging updated: Removing @Cause annotation

This is an automated email from the ASF dual-hosted git repository.

clebertsuconic pushed a commit to branch new-logging
in repository https://gitbox.apache.org/repos/asf/activemq-artemis.git


The following commit(s) were added to refs/heads/new-logging by this push:
     new 59610c1673 Removing @Cause annotation
59610c1673 is described below

commit 59610c1673000482f843b1b80e664b703eeffffa
Author: Clebert Suconic <cl...@apache.org>
AuthorDate: Thu Jul 21 11:52:03 2022 -0400

    Removing @Cause annotation
---
 .../activemq/artemis/logs/ActiveMQUtilBundle.java  |   3 +-
 .../activemq/artemis/logs/ActiveMQUtilLogger.java  |  21 +-
 .../apache/activemq/artemis/logs/AuditLogger.java  |   3 +-
 .../artemis/core/client/ActiveMQClientLogger.java  | 119 ++++---
 .../core/client/ActiveMQClientMessageBundle.java   |  21 +-
 .../jms/client/ActiveMQJMSClientBundle.java        |   3 +-
 .../jms/client/ActiveMQJMSClientLogger.java        |  17 +-
 .../jms/bridge/ActiveMQJMSBridgeLogger.java        |  11 +-
 .../jms/server/ActiveMQJMSServerBundle.java        |   3 +-
 .../jms/server/ActiveMQJMSServerLogger.java        |  17 +-
 .../artemis/journal/ActiveMQJournalLogger.java     |  39 ++-
 .../artemis/logprocessor/annotation/Cause.java     |  30 --
 .../artemis/core/protocol/mqtt/MQTTLogger.java     |  17 +-
 .../stomp/ActiveMQStompProtocolLogger.java         |   3 +-
 .../stomp/ActiveMQStompProtocolMessageBundle.java  |  19 +-
 .../activemq/artemis/ra/ActiveMQRABundle.java      |   3 +-
 .../activemq/artemis/ra/ActiveMQRALogger.java      |  27 +-
 .../activemq/artemis/rest/ActiveMQRestLogger.java  |  11 +-
 .../activemq/artemis/osgi/ActiveMQOsgiLogger.java  |   7 +-
 .../artemis/core/server/ActiveMQMessageBundle.java |  11 +-
 .../artemis/core/server/ActiveMQServerLogger.java  | 361 ++++++++++-----------
 .../xa/recovery/ActiveMQXARecoveryLogger.java      |  17 +-
 22 files changed, 356 insertions(+), 407 deletions(-)

diff --git a/artemis-commons/src/main/java/org/apache/activemq/artemis/logs/ActiveMQUtilBundle.java b/artemis-commons/src/main/java/org/apache/activemq/artemis/logs/ActiveMQUtilBundle.java
index a04c138e97..4c4de7882a 100644
--- a/artemis-commons/src/main/java/org/apache/activemq/artemis/logs/ActiveMQUtilBundle.java
+++ b/artemis-commons/src/main/java/org/apache/activemq/artemis/logs/ActiveMQUtilBundle.java
@@ -18,7 +18,6 @@ package org.apache.activemq.artemis.logs;
 
 import org.apache.activemq.artemis.api.core.ActiveMQIllegalStateException;
 import org.apache.activemq.artemis.logprocessor.CodeFactory;
-import org.apache.activemq.artemis.logprocessor.annotation.Cause;
 import org.apache.activemq.artemis.logprocessor.annotation.LogBundle;
 import org.apache.activemq.artemis.logprocessor.annotation.Message;
 
@@ -44,7 +43,7 @@ public interface ActiveMQUtilBundle {
    IllegalStateException stringTooLong(Integer length);
 
    @Message(id = 209003, value = "Error instantiating codec {}")
-   IllegalArgumentException errorCreatingCodec(String codecClassName, @Cause Exception e);
+   IllegalArgumentException errorCreatingCodec(String codecClassName, Exception e);
 
    @Message(id = 209004, value = "Failed to parse long value from {}")
    IllegalArgumentException failedToParseLong(String value);
diff --git a/artemis-commons/src/main/java/org/apache/activemq/artemis/logs/ActiveMQUtilLogger.java b/artemis-commons/src/main/java/org/apache/activemq/artemis/logs/ActiveMQUtilLogger.java
index d31c4f70b7..9bd7120145 100644
--- a/artemis-commons/src/main/java/org/apache/activemq/artemis/logs/ActiveMQUtilLogger.java
+++ b/artemis-commons/src/main/java/org/apache/activemq/artemis/logs/ActiveMQUtilLogger.java
@@ -17,7 +17,6 @@
 package org.apache.activemq.artemis.logs;
 
 import org.apache.activemq.artemis.logprocessor.CodeFactory;
-import org.apache.activemq.artemis.logprocessor.annotation.Cause;
 import org.apache.activemq.artemis.logprocessor.annotation.LogBundle;
 import org.apache.activemq.artemis.logprocessor.annotation.LogMessage;
 
@@ -48,37 +47,37 @@ public interface ActiveMQUtilLogger {
    void urlWasntReacheable(String url);
 
    @LogMessage(id = 202004, value = "Error starting component {} ", level = LogMessage.Level.WARN)
-   void errorStartingComponent(String component, @Cause Exception e);
+   void errorStartingComponent(String component, Exception e);
 
    @LogMessage(id = 202005, value = "Error stopping component {} ", level = LogMessage.Level.WARN)
-   void errorStoppingComponent(String component, @Cause Exception e);
+   void errorStoppingComponent(String component, Exception e);
 
    @LogMessage(id = 202006, value = "Failed to check Url {}.", level = LogMessage.Level.WARN)
-   void failedToCheckURL(String url, @Cause Exception e);
+   void failedToCheckURL(String url, Exception e);
 
    @LogMessage(id = 202007, value = "Failed to check Address {}.", level = LogMessage.Level.WARN)
-   void failedToCheckAddress(String address, @Cause Exception e);
+   void failedToCheckAddress(String address, Exception e);
 
    @LogMessage(id = 202008, value = "Failed to check Address list {}.", level = LogMessage.Level.WARN)
-   void failedToParseAddressList(String addressList, @Cause Exception e);
+   void failedToParseAddressList(String addressList, Exception e);
 
    @LogMessage(id = 202009, value = "Failed to check Url list {}.", level = LogMessage.Level.WARN)
-   void failedToParseUrlList(String urlList, @Cause Exception e);
+   void failedToParseUrlList(String urlList, Exception e);
 
    @LogMessage(id = 202010, value = "Failed to set NIC {}.", level = LogMessage.Level.WARN)
-   void failedToSetNIC(String nic, @Cause Exception e);
+   void failedToSetNIC(String nic, Exception e);
 
    @LogMessage(id = 202011, value = "Failed to read from stream {}.", level = LogMessage.Level.WARN)
    void failedToReadFromStream(String stream);
 
    @LogMessage(id = 202012, value = "Object cannot be serialized.", level = LogMessage.Level.WARN)
-   void failedToSerializeObject(@Cause Exception e);
+   void failedToSerializeObject(Exception e);
 
    @LogMessage(id = 202013, value = "Unable to deserialize object.", level = LogMessage.Level.WARN)
-   void failedToDeserializeObject(@Cause Exception e);
+   void failedToDeserializeObject(Exception e);
 
    @LogMessage(id = 202014, value = "Unable to encode byte array into Base64 notation.", level = LogMessage.Level.WARN)
-   void failedToEncodeByteArrayToBase64Notation(@Cause Exception e);
+   void failedToEncodeByteArrayToBase64Notation(Exception e);
 
    @LogMessage(id = 202015, value = "Failed to clean up file {}", level = LogMessage.Level.WARN)
    void failedToCleanupFile(String file);
diff --git a/artemis-commons/src/main/java/org/apache/activemq/artemis/logs/AuditLogger.java b/artemis-commons/src/main/java/org/apache/activemq/artemis/logs/AuditLogger.java
index 9dae59cf7d..705f3af314 100644
--- a/artemis-commons/src/main/java/org/apache/activemq/artemis/logs/AuditLogger.java
+++ b/artemis-commons/src/main/java/org/apache/activemq/artemis/logs/AuditLogger.java
@@ -18,7 +18,6 @@ package org.apache.activemq.artemis.logs;
 
 import org.apache.activemq.artemis.logprocessor.CodeFactory;
 import org.apache.activemq.artemis.logprocessor.annotation.LogBundle;
-import org.apache.activemq.artemis.logprocessor.annotation.Cause;
 import org.apache.activemq.artemis.logprocessor.annotation.GetLogger;
 import org.apache.activemq.artemis.logprocessor.annotation.LogMessage;
 import org.slf4j.Logger;
@@ -2000,7 +1999,7 @@ public interface AuditLogger {
    }
 
    @LogMessage(id = 601264, value = "User {} gets security check failure", level = LogMessage.Level.INFO)
-   void securityFailure(String user, @Cause Throwable cause);
+   void securityFailure(String user, Throwable cause);
 
 
    static void createCoreConsumer(Object source, Subject user, String remoteAddress, Object... args) {
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/client/ActiveMQClientLogger.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/client/ActiveMQClientLogger.java
index 8f27c585a7..0480e9a247 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/client/ActiveMQClientLogger.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/client/ActiveMQClientLogger.java
@@ -21,7 +21,6 @@ import java.net.UnknownHostException;
 import org.apache.activemq.artemis.api.core.ActiveMQExceptionType;
 import org.apache.activemq.artemis.api.core.Interceptor;
 import org.apache.activemq.artemis.logprocessor.CodeFactory;
-import org.apache.activemq.artemis.logprocessor.annotation.Cause;
 import org.apache.activemq.artemis.logprocessor.annotation.LogBundle;
 import org.apache.activemq.artemis.logprocessor.annotation.LogMessage;
 import org.w3c.dom.Node;
@@ -35,13 +34,13 @@ public interface ActiveMQClientLogger {
    ActiveMQClientLogger LOGGER = CodeFactory.getCodeClass(ActiveMQClientLogger.class, ActiveMQClientLogger.class.getPackage().getName());
 
    @LogMessage(id = 212001, value = "Error on clearing messages", level = LogMessage.Level.WARN)
-   void errorClearingMessages(@Cause Throwable e);
+   void errorClearingMessages(Throwable e);
 
    @LogMessage(id = 212002, value = "Timed out waiting for handler to complete processing", level = LogMessage.Level.WARN)
    void timeOutWaitingForProcessing();
 
    @LogMessage(id = 212003, value = "Unable to close session", level = LogMessage.Level.WARN)
-   void unableToCloseSession(@Cause Exception e);
+   void unableToCloseSession(Exception e);
 
    @LogMessage(id = 212004, value = "Failed to connect to server.", level = LogMessage.Level.WARN)
    void failedToConnectToServer();
@@ -50,10 +49,10 @@ public interface ActiveMQClientLogger {
    void failedToConnectToServer(Integer reconnectAttempts);
 
    @LogMessage(id = 212007, value = "connector.create or connectorFactory.createConnector should never throw an exception, implementation is badly behaved, but we will deal with it anyway.", level = LogMessage.Level.WARN)
-   void createConnectorException(@Cause Exception e);
+   void createConnectorException(Exception e);
 
    @LogMessage(id = 212008, value = "I am closing a core ClientSessionFactory you left open. Please make sure you close all ClientSessionFactories explicitly " + "before letting them go out of scope! {}", level = LogMessage.Level.WARN)
-   void factoryLeftOpen(int i, @Cause Exception e);
+   void factoryLeftOpen(int i, Exception e);
 
    @LogMessage(id = 212009, value = "resetting session after failure", level = LogMessage.Level.WARN)
    void resettingSessionAfterFailure();
@@ -71,37 +70,37 @@ public interface ActiveMQClientLogger {
    void failoverDuringPrepareRollingBack();
 
    @LogMessage(id = 212015, value = "failover occurred during prepare rolling back", level = LogMessage.Level.WARN)
-   void errorDuringPrepare(@Cause Throwable e);
+   void errorDuringPrepare(Throwable e);
 
    @LogMessage(id = 212016, value = "I am closing a core ClientSession you left open. Please make sure you close all ClientSessions explicitly before letting them go out of scope! {}", level = LogMessage.Level.WARN)
-   void clientSessionNotClosed(int identity, @Cause Exception e);
+   void clientSessionNotClosed(int identity, Exception e);
 
    @LogMessage(id = 212017, value = "error adding packet", level = LogMessage.Level.WARN)
-   void errorAddingPacket(@Cause Exception e);
+   void errorAddingPacket(Exception e);
 
    @LogMessage(id = 212018, value = "error calling cancel", level = LogMessage.Level.WARN)
-   void errorCallingCancel(@Cause Exception e);
+   void errorCallingCancel(Exception e);
 
    @LogMessage(id = 212019, value = "error reading index", level = LogMessage.Level.WARN)
-   void errorReadingIndex(@Cause Exception e);
+   void errorReadingIndex(Exception e);
 
    @LogMessage(id = 212020, value = "error setting index", level = LogMessage.Level.WARN)
-   void errorSettingIndex(@Cause Exception e);
+   void errorSettingIndex(Exception e);
 
    @LogMessage(id = 212021, value = "error resetting index", level = LogMessage.Level.WARN)
-   void errorReSettingIndex(@Cause Exception e);
+   void errorReSettingIndex(Exception e);
 
    @LogMessage(id = 212022, value = "error reading LargeMessage file cache", level = LogMessage.Level.WARN)
-   void errorReadingCache(@Cause Exception e);
+   void errorReadingCache(Exception e);
 
    @LogMessage(id = 212023, value = "error closing LargeMessage file cache", level = LogMessage.Level.WARN)
-   void errorClosingCache(@Cause Exception e);
+   void errorClosingCache(Exception e);
 
    @LogMessage(id = 212024, value = "Exception during finalization for LargeMessage file cache", level = LogMessage.Level.WARN)
-   void errorFinalisingCache(@Cause Exception e);
+   void errorFinalisingCache(Exception e);
 
    @LogMessage(id = 212025, value = "did not connect the cluster connection to other nodes", level = LogMessage.Level.WARN)
-   void errorConnectingToNodes(@Cause Exception e);
+   void errorConnectingToNodes(Exception e);
 
    @LogMessage(id = 212026, value = "Timed out waiting for pool to terminate", level = LogMessage.Level.WARN)
    void timedOutWaitingForTermination();
@@ -110,26 +109,26 @@ public interface ActiveMQClientLogger {
    void timedOutWaitingForScheduledPoolTermination();
 
    @LogMessage(id = 212028, value = "error starting server locator", level = LogMessage.Level.WARN)
-   void errorStartingLocator(@Cause Exception e);
+   void errorStartingLocator(Exception e);
 
 
    @LogMessage(id = 212030, value = "error sending topology", level = LogMessage.Level.WARN)
-   void errorSendingTopology(@Cause Throwable e);
+   void errorSendingTopology(Throwable e);
 
    @LogMessage(id = 212031, value = "error sending topology", level = LogMessage.Level.WARN)
-   void errorSendingTopologyNodedown(@Cause Throwable e);
+   void errorSendingTopologyNodedown(Throwable e);
 
    @LogMessage(id = 212032, value = "Timed out waiting to stop discovery thread", level = LogMessage.Level.WARN)
    void timedOutStoppingDiscovery();
 
    @LogMessage(id = 212033, value = "unable to send notification when discovery group is stopped", level = LogMessage.Level.WARN)
-   void errorSendingNotifOnDiscoveryStop(@Cause Throwable e);
+   void errorSendingNotifOnDiscoveryStop(Throwable e);
 
    @LogMessage(id = 212034, value = "There are more than one servers on the network broadcasting the same node id. " + "You will see this message exactly once (per node) if a node is restarted, in which case it can be safely " + "ignored. But if it is logged continuously it means you really do have more than one node on the same network " + "active concurrently with the same node id. This could occur if you have a backup node active at the same time as " + "its live node. nodeID={}", lev [...]
    void multipleServersBroadcastingSameNode(String nodeId);
 
    @LogMessage(id = 212035, value = "error receiving packet in discovery", level = LogMessage.Level.WARN)
-   void errorReceivingPacketInDiscovery(@Cause Throwable e);
+   void errorReceivingPacketInDiscovery(Throwable e);
 
    @LogMessage(id = 212036, value = "Can not find packet to clear: {} last received command id first stored command id {}", level = LogMessage.Level.WARN)
    void cannotFindPacketToClear(Integer lastReceivedCommandID, Integer firstStoredCommandID);
@@ -138,7 +137,7 @@ public interface ActiveMQClientLogger {
    void connectionFailureDetected(String remoteAddress, String message, ActiveMQExceptionType type);
 
    @LogMessage(id = 212038, value = "Failure in calling interceptor: {}", level = LogMessage.Level.WARN)
-   void errorCallingInterceptor(Interceptor interceptor, @Cause Throwable e);
+   void errorCallingInterceptor(Interceptor interceptor, Throwable e);
 
    @LogMessage(id = 212040, value = "Timed out waiting for netty ssl close future to complete", level = LogMessage.Level.WARN)
    void timeoutClosingSSL();
@@ -165,7 +164,7 @@ public interface ActiveMQClientLogger {
    void jvmAllocatedMoreMemory(Long totalMemory1, Long totalMemory2);
 
    @LogMessage(id = 212048, value = "Random address ({}) was already in use, trying another time", level = LogMessage.Level.WARN)
-   void broadcastGroupBindErrorRetry(String hostAndPort, @Cause Throwable t);
+   void broadcastGroupBindErrorRetry(String hostAndPort, Throwable t);
 
    @LogMessage(id = 212049, value = "Could not bind to {} ({} address); " + "make sure your discovery group-address is of the same type as the IP stack (IPv4 or IPv6)." + "\nIgnoring discovery group-address, but this may lead to cross talking.", level = LogMessage.Level.WARN)
    void ioDiscoveryError(String hostAddress, String s);
@@ -174,10 +173,10 @@ public interface ActiveMQClientLogger {
    void compressedLargeMessageError(int length, int nReadBytes);
 
    @LogMessage(id = 212051, value = "Invalid concurrent session usage. Sessions are not supposed to be used by more than one thread concurrently.", level = LogMessage.Level.WARN)
-   void invalidConcurrentSessionUsage(@Cause Throwable t);
+   void invalidConcurrentSessionUsage(Throwable t);
 
    @LogMessage(id = 212052, value = "Packet {} was answered out of sequence due to a previous server timeout and it's being ignored", level = LogMessage.Level.WARN)
-   void packetOutOfOrder(Object obj, @Cause Throwable t);
+   void packetOutOfOrder(Object obj, Throwable t);
 
    /**
     * Warns about usage of {@link org.apache.activemq.artemis.api.core.client.SendAcknowledgementHandler} or JMS's {@code CompletionWindow} with
@@ -191,7 +190,7 @@ public interface ActiveMQClientLogger {
    void outOfCreditOnFlowControl(String address);
 
    @LogMessage(id = 212055, value = "Unable to close consumer", level = LogMessage.Level.WARN)
-   void unableToCloseConsumer(@Cause Exception e);
+   void unableToCloseConsumer(Exception e);
 
    @LogMessage(id = 212056, value = "local-bind-address specified for broadcast group but no local-bind-port. Using random port for UDP Broadcast ({})", level = LogMessage.Level.WARN)
    void broadcastGroupBindError(String hostAndPort);
@@ -200,7 +199,7 @@ public interface ActiveMQClientLogger {
    void timeoutStreamingLargeMessage();
 
    @LogMessage(id = 212058, value = "Unable to get a message.", level = LogMessage.Level.WARN)
-   void unableToGetMessage(@Cause Exception e);
+   void unableToGetMessage(Exception e);
 
    @LogMessage(id = 212059, value = "Failed to clean up: {} ", level = LogMessage.Level.WARN)
    void failedCleaningUp(String target);
@@ -209,25 +208,25 @@ public interface ActiveMQClientLogger {
    void unexpectedNullDataReceived();
 
    @LogMessage(id = 212061, value = "Failed to perform force close ", level = LogMessage.Level.WARN)
-   void failedForceClose(@Cause Throwable e);
+   void failedForceClose(Throwable e);
 
    @LogMessage(id = 212062, value = "Failed to perform post actions on message processing ", level = LogMessage.Level.WARN)
-   void failedPerformPostActionsOnMessage(@Cause Exception e);
+   void failedPerformPostActionsOnMessage(Exception e);
 
    @LogMessage(id = 212063, value = "Unable to handle connection failure ", level = LogMessage.Level.WARN)
-   void unableToHandleConnectionFailure(@Cause Throwable e);
+   void unableToHandleConnectionFailure(Throwable e);
 
    @LogMessage(id = 212064, value = "Unable to receive cluster topology ", level = LogMessage.Level.WARN)
-   void unableToReceiveClusterTopology(@Cause Throwable e);
+   void unableToReceiveClusterTopology(Throwable e);
 
    @LogMessage(id = 212065, value = "{} getting exception when receiving broadcasting ", level = LogMessage.Level.WARN)
-   void unableToReceiveBroadcast(String target, @Cause Exception e);
+   void unableToReceiveBroadcast(String target, Exception e);
 
    @LogMessage(id = 212066, value = "failed to parse int property ", level = LogMessage.Level.WARN)
-   void unableToParseValue(@Cause Throwable e);
+   void unableToParseValue(Throwable e);
 
    @LogMessage(id = 212067, value = "failed to get system property ", level = LogMessage.Level.WARN)
-   void unableToGetProperty(@Cause Throwable e);
+   void unableToGetProperty(Throwable e);
 
    @LogMessage(id = 212068, value = "Couldn't finish the client globalThreadPool in less than 10 seconds, interrupting it now ", level = LogMessage.Level.WARN)
    void unableToProcessGlobalThreadPoolIn10Sec();
@@ -236,16 +235,16 @@ public interface ActiveMQClientLogger {
    void unableToProcessScheduledlIn10Sec();
 
    @LogMessage(id = 212070, value = "Unable to initialize VersionLoader ", level = LogMessage.Level.WARN)
-   void unableToInitVersionLoader(@Cause Throwable e);
+   void unableToInitVersionLoader(Throwable e);
 
    @LogMessage(id = 212071, value = "Unable to check Epoll availability ", level = LogMessage.Level.WARN)
-   void unableToCheckEpollAvailability(@Cause Throwable e);
+   void unableToCheckEpollAvailability(Throwable e);
 
    @LogMessage(id = 212072, value = "Failed to change channel state to ReadyForWriting ", level = LogMessage.Level.WARN)
-   void failedToSetChannelReadyForWriting(@Cause Throwable e);
+   void failedToSetChannelReadyForWriting(Throwable e);
 
    @LogMessage(id = 212073, value = "Unable to check KQueue availability ", level = LogMessage.Level.WARN)
-   void unableToCheckKQueueAvailability(@Cause Throwable e);
+   void unableToCheckKQueueAvailability(Throwable e);
 
    @LogMessage(id = 212075, value = "KQueue is not available, please add to the classpath or configure useKQueue=false to remove this warning", level = LogMessage.Level.WARN)
    void unableToCheckKQueueAvailabilityNoClass();
@@ -263,19 +262,19 @@ public interface ActiveMQClientLogger {
    void oldStoreProvider(String value);
 
    @LogMessage(id = 214000, value = "Failed to call onMessage", level = LogMessage.Level.ERROR)
-   void onMessageError(@Cause Throwable e);
+   void onMessageError(Throwable e);
 
    @LogMessage(id = 214001, value = "failed to cleanup session", level = LogMessage.Level.ERROR)
-   void failedToCleanupSession(@Cause Exception e);
+   void failedToCleanupSession(Exception e);
 
    @LogMessage(id = 214002, value = "Failed to execute failure listener", level = LogMessage.Level.ERROR)
-   void failedToExecuteListener(@Cause Throwable t);
+   void failedToExecuteListener(Throwable t);
 
    @LogMessage(id = 214003, value = "Failed to handle failover", level = LogMessage.Level.ERROR)
-   void failedToHandleFailover(@Cause Throwable t);
+   void failedToHandleFailover(Throwable t);
 
    @LogMessage(id = 214004, value = "XA end operation failed ", level = LogMessage.Level.ERROR)
-   void errorCallingEnd(@Cause Throwable t);
+   void errorCallingEnd(Throwable t);
 
    @LogMessage(id = 214005, value = "XA start operation failed {} code:{}", level = LogMessage.Level.ERROR)
    void errorCallingStart(String message, Integer code);
@@ -284,43 +283,43 @@ public interface ActiveMQClientLogger {
    void sessionNotXA();
 
    @LogMessage(id = 214007, value = "Received exception asynchronously from server", level = LogMessage.Level.ERROR)
-   void receivedExceptionAsynchronously(@Cause Exception e);
+   void receivedExceptionAsynchronously(Exception e);
 
    @LogMessage(id = 214008, value = "Failed to handle packet", level = LogMessage.Level.ERROR)
-   void failedToHandlePacket(@Cause Exception e);
+   void failedToHandlePacket(Exception e);
 
    @LogMessage(id = 214009, value = "Failed to stop discovery group", level = LogMessage.Level.ERROR)
-   void failedToStopDiscovery(@Cause Throwable e);
+   void failedToStopDiscovery(Throwable e);
 
    @LogMessage(id = 214010, value = "Failed to receive datagram", level = LogMessage.Level.ERROR)
-   void failedToReceiveDatagramInDiscovery(@Cause Throwable e);
+   void failedToReceiveDatagramInDiscovery(Throwable e);
 
    @LogMessage(id = 214011, value = "Failed to call discovery listener", level = LogMessage.Level.ERROR)
-   void failedToCallListenerInDiscovery(@Cause Throwable e);
+   void failedToCallListenerInDiscovery(Throwable e);
 
    @LogMessage(id = 214013, value = "Failed to decode packet", level = LogMessage.Level.ERROR)
-   void errorDecodingPacket(@Cause Throwable e);
+   void errorDecodingPacket(Throwable e);
 
    @LogMessage(id = 214014, value = "Failed to execute failure listener", level = LogMessage.Level.ERROR)
-   void errorCallingFailureListener(@Cause Throwable e);
+   void errorCallingFailureListener(Throwable e);
 
    @LogMessage(id = 214015, value = "Failed to execute connection life cycle listener", level = LogMessage.Level.ERROR)
-   void errorCallingLifeCycleListener(@Cause Throwable e);
+   void errorCallingLifeCycleListener(Throwable e);
 
    @LogMessage(id = 214016, value = "Failed to create netty connection", level = LogMessage.Level.ERROR)
-   void errorCreatingNettyConnection(@Cause Throwable e);
+   void errorCreatingNettyConnection(Throwable e);
 
    @LogMessage(id = 214017, value = "Caught unexpected Throwable", level = LogMessage.Level.ERROR)
-   void caughtunexpectedThrowable(@Cause Throwable t);
+   void caughtunexpectedThrowable(Throwable t);
 
    @LogMessage(id = 214018, value = "Failed to invoke getTextContent() on node {}", level = LogMessage.Level.ERROR)
-   void errorOnXMLTransform(Node n, @Cause Throwable t);
+   void errorOnXMLTransform(Node n, Throwable t);
 
    @LogMessage(id = 214019, value = "Invalid configuration", level = LogMessage.Level.ERROR)
-   void errorOnXMLTransformInvalidConf(@Cause Throwable t);
+   void errorOnXMLTransformInvalidConf(Throwable t);
 
    @LogMessage(id = 214020, value = "Exception happened while stopping Discovery BroadcastEndpoint {}", level = LogMessage.Level.ERROR)
-   void errorStoppingDiscoveryBroadcastEndpoint(Object endpoint, @Cause Throwable t);
+   void errorStoppingDiscoveryBroadcastEndpoint(Object endpoint, Throwable t);
 
    @LogMessage(id = 214021, value = "Invalid cipher suite specified. Supported cipher suites are: {}", level = LogMessage.Level.ERROR)
    void invalidCipherSuite(String validSuites);
@@ -335,14 +334,14 @@ public interface ActiveMQClientLogger {
    void unexpectedResponseFromHttpServer(Object response);
 
    @LogMessage(id = 214030, value = "Failed to bind {}={}", level = LogMessage.Level.ERROR)
-   void failedToBind(String p1, String p2, @Cause Throwable cause);
+   void failedToBind(String p1, String p2, Throwable cause);
 
    @LogMessage(id = 214031, value = "Failed to decode buffer, disconnect immediately.", level = LogMessage.Level.ERROR)
-   void disconnectOnErrorDecoding(@Cause Throwable cause);
+   void disconnectOnErrorDecoding(Throwable cause);
 
    @LogMessage(id = 214032, value = "Unable to initialize VersionLoader ", level = LogMessage.Level.ERROR)
-   void unableToInitVersionLoaderError(@Cause Throwable e);
+   void unableToInitVersionLoaderError(Throwable e);
 
    @LogMessage(id = 214033, value = "Cannot resolve host ", level = LogMessage.Level.ERROR)
-   void unableToResolveHost(@Cause UnknownHostException e);
+   void unableToResolveHost(UnknownHostException e);
 }
diff --git a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/client/ActiveMQClientMessageBundle.java b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/client/ActiveMQClientMessageBundle.java
index 41970dbe72..92d14e7a4a 100644
--- a/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/client/ActiveMQClientMessageBundle.java
+++ b/artemis-core-client/src/main/java/org/apache/activemq/artemis/core/client/ActiveMQClientMessageBundle.java
@@ -33,7 +33,6 @@ import org.apache.activemq.artemis.api.core.ActiveMQTransactionRolledBackExcepti
 import org.apache.activemq.artemis.api.core.ActiveMQUnBlockedException;
 import org.apache.activemq.artemis.core.cluster.DiscoveryGroup;
 import org.apache.activemq.artemis.logprocessor.CodeFactory;
-import org.apache.activemq.artemis.logprocessor.annotation.Cause;
 import org.apache.activemq.artemis.logprocessor.annotation.LogBundle;
 import org.apache.activemq.artemis.logprocessor.annotation.Message;
 import org.apache.activemq.artemis.spi.core.remoting.Connection;
@@ -55,13 +54,13 @@ public interface ActiveMQClientMessageBundle {
    ActiveMQInternalErrorException clientSessionClosed();
 
    @Message(id = 219001, value = "Failed to create session")
-   ActiveMQInternalErrorException failedToCreateSession(@Cause Throwable t);
+   ActiveMQInternalErrorException failedToCreateSession(Throwable t);
 
    @Message(id = 219003, value = "Queue can not be both durable and temporary")
    ActiveMQInternalErrorException queueMisConfigured();
 
    @Message(id = 219004, value = "Failed to initialise session factory")
-   ActiveMQInternalErrorException failedToInitialiseSessionFactory(@Cause Exception e);
+   ActiveMQInternalErrorException failedToInitialiseSessionFactory(Exception e);
 
    @Message(id = 219005, value = "Exception in Netty transport")
    ActiveMQInternalErrorException nettyError();
@@ -73,7 +72,7 @@ public interface ActiveMQClientMessageBundle {
    ActiveMQNotConnectedException cannotConnectToServers();
 
    @Message(id = 219008, value = "Failed to connect to any static connectors")
-   ActiveMQNotConnectedException cannotConnectToStaticConnectors(@Cause Exception e);
+   ActiveMQNotConnectedException cannotConnectToStaticConnectors(Exception e);
 
    @Message(id = 219009, value = "Failed to connect to any static connectors")
    ActiveMQNotConnectedException cannotConnectToStaticConnectors2();
@@ -97,7 +96,7 @@ public interface ActiveMQClientMessageBundle {
    ActiveMQDisconnectedException disconnected();
 
    @Message(id = 219016, value = "Connection failure detected. Unblocking a blocking call that will never get a response")
-   ActiveMQUnBlockedException unblockingACall(@Cause Throwable t);
+   ActiveMQUnBlockedException unblockingACall(Throwable t);
 
    @Message(id = 219017, value = "Consumer is closed")
    ActiveMQObjectClosedException consumerClosed();
@@ -124,19 +123,19 @@ public interface ActiveMQClientMessageBundle {
    ActiveMQIllegalStateException noTCForSessionFactory();
 
    @Message(id = 219025, value = "Error saving the message body")
-   ActiveMQLargeMessageException errorSavingBody(@Cause Exception e);
+   ActiveMQLargeMessageException errorSavingBody(Exception e);
 
    @Message(id = 219026, value = "Error reading the LargeMessageBody")
-   ActiveMQLargeMessageException errorReadingBody(@Cause Exception e);
+   ActiveMQLargeMessageException errorReadingBody(Exception e);
 
    @Message(id = 219027, value = "Error closing stream from LargeMessageBody")
-   ActiveMQLargeMessageException errorClosingLargeMessage(@Cause Exception e);
+   ActiveMQLargeMessageException errorClosingLargeMessage(Exception e);
 
    @Message(id = 219028, value = "Timeout waiting for LargeMessage Body")
    ActiveMQLargeMessageException timeoutOnLargeMessage();
 
    @Message(id = 219029, value = "Error writing body of message")
-   ActiveMQLargeMessageException errorWritingLargeMessage(@Cause Exception e);
+   ActiveMQLargeMessageException errorWritingLargeMessage(Exception e);
 
    @Message(id = 219030, value = "The transaction was rolled back on failover to a backup server")
    ActiveMQTransactionRolledBackException txRolledBack();
@@ -211,7 +210,7 @@ public interface ActiveMQClientMessageBundle {
    IllegalArgumentException mustBeLong(Node element, String value);
 
    @Message(id = 219057, value = "Error decoding password")
-   IllegalArgumentException errordecodingPassword(@Cause Exception e);
+   IllegalArgumentException errordecodingPassword(Exception e);
 
    @Message(id = 219058, value = "Address \"{}\" is full. Message encode size = {}B")
    ActiveMQAddressFullException addressIsFull(String addressName, int size);
@@ -235,7 +234,7 @@ public interface ActiveMQClientMessageBundle {
    IllegalStateException invalidPacket(byte type);
 
    @Message(id = 219065, value = "Failed to handle packet.")
-   RuntimeException failedToHandlePacket(@Cause Exception e);
+   RuntimeException failedToHandlePacket(Exception e);
 
    @Message(id = 219066, value = "The connection was redirected")
    ActiveMQRoutingException redirected();
diff --git a/artemis-jms-client/src/main/java/org/apache/activemq/artemis/jms/client/ActiveMQJMSClientBundle.java b/artemis-jms-client/src/main/java/org/apache/activemq/artemis/jms/client/ActiveMQJMSClientBundle.java
index 9f9a642ba8..efeb11258a 100644
--- a/artemis-jms-client/src/main/java/org/apache/activemq/artemis/jms/client/ActiveMQJMSClientBundle.java
+++ b/artemis-jms-client/src/main/java/org/apache/activemq/artemis/jms/client/ActiveMQJMSClientBundle.java
@@ -29,7 +29,6 @@ import org.apache.activemq.artemis.api.core.ActiveMQInvalidFilterExpressionExcep
 import org.apache.activemq.artemis.api.core.ActiveMQNonExistentQueueException;
 import org.apache.activemq.artemis.api.core.SimpleString;
 import org.apache.activemq.artemis.logprocessor.CodeFactory;
-import org.apache.activemq.artemis.logprocessor.annotation.Cause;
 import org.apache.activemq.artemis.logprocessor.annotation.LogBundle;
 import org.apache.activemq.artemis.logprocessor.annotation.Message;
 
@@ -46,7 +45,7 @@ public interface ActiveMQJMSClientBundle {
    ActiveMQJMSClientBundle BUNDLE = CodeFactory.getCodeClass(ActiveMQJMSClientBundle.class);
 
    @Message(id = 139000, value = "Invalid filter: {}")
-   ActiveMQInvalidFilterExpressionException invalidFilter(SimpleString filter, @Cause Throwable e);
+   ActiveMQInvalidFilterExpressionException invalidFilter(SimpleString filter, Throwable e);
 
    @Message(id = 139001, value = "Invalid Subscription Name. It is required to set the subscription name")
    ActiveMQIllegalStateException invalidSubscriptionName();
diff --git a/artemis-jms-client/src/main/java/org/apache/activemq/artemis/jms/client/ActiveMQJMSClientLogger.java b/artemis-jms-client/src/main/java/org/apache/activemq/artemis/jms/client/ActiveMQJMSClientLogger.java
index f2f81030ba..e48bdc6f54 100644
--- a/artemis-jms-client/src/main/java/org/apache/activemq/artemis/jms/client/ActiveMQJMSClientLogger.java
+++ b/artemis-jms-client/src/main/java/org/apache/activemq/artemis/jms/client/ActiveMQJMSClientLogger.java
@@ -17,7 +17,6 @@
 package org.apache.activemq.artemis.jms.client;
 
 import org.apache.activemq.artemis.logprocessor.CodeFactory;
-import org.apache.activemq.artemis.logprocessor.annotation.Cause;
 import org.apache.activemq.artemis.logprocessor.annotation.LogBundle;
 import org.apache.activemq.artemis.logprocessor.annotation.LogMessage;
 
@@ -41,27 +40,27 @@ public interface ActiveMQJMSClientLogger {
    ActiveMQJMSClientLogger LOGGER = CodeFactory.getCodeClass(ActiveMQJMSClientLogger.class, ActiveMQJMSClientLogger.class.getPackage().getName());
 
    @LogMessage(id = 132000, value = "I'm closing a JMS connection you left open. Please make sure you close all JMS connections explicitly before letting them go out of scope! see stacktrace to find out where it was created", level = LogMessage.Level.WARN)
-   void connectionLeftOpen(@Cause Exception e);
+   void connectionLeftOpen(Exception e);
 
    @LogMessage(id = 132001, value = "Unhandled exception thrown from onMessage", level = LogMessage.Level.WARN)
-   void onMessageError(@Cause Exception e);
+   void onMessageError(Exception e);
 
    @LogMessage(id = 134000, value = "Failed to call JMS exception listener", level = LogMessage.Level.ERROR)
-   void errorCallingExcListener(@Cause Exception e);
+   void errorCallingExcListener(Exception e);
 
    @LogMessage(id = 134002, value = "Queue Browser failed to create message {}", level = LogMessage.Level.ERROR)
-   void errorCreatingMessage(String messageToString, @Cause Throwable e);
+   void errorCreatingMessage(String messageToString, Throwable e);
 
    @LogMessage(id = 134003, value = "Message Listener failed to prepare message for receipt, message={}", level = LogMessage.Level.ERROR)
-   void errorPreparingMessageForReceipt(String messagetoString, @Cause Throwable e);
+   void errorPreparingMessageForReceipt(String messagetoString, Throwable e);
 
    @LogMessage(id = 134004, value = "Message Listener failed to process message", level = LogMessage.Level.ERROR)
-   void errorProcessingMessage(@Cause Throwable e);
+   void errorProcessingMessage(Throwable e);
 
    @LogMessage(id = 134005, value = "Message Listener failed to recover session", level = LogMessage.Level.ERROR)
-   void errorRecoveringSession(@Cause Throwable e);
+   void errorRecoveringSession(Throwable e);
 
    @LogMessage(id = 134006, value = "Failed to call Failover listener", level = LogMessage.Level.ERROR)
-   void errorCallingFailoverListener(@Cause Exception e);
+   void errorCallingFailoverListener(Exception e);
 
 }
diff --git a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/bridge/ActiveMQJMSBridgeLogger.java b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/bridge/ActiveMQJMSBridgeLogger.java
index 8c75b5d4f9..d303f97ea4 100644
--- a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/bridge/ActiveMQJMSBridgeLogger.java
+++ b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/bridge/ActiveMQJMSBridgeLogger.java
@@ -19,7 +19,6 @@ package org.apache.activemq.artemis.jms.bridge;
 import javax.management.ObjectName;
 
 import org.apache.activemq.artemis.logprocessor.CodeFactory;
-import org.apache.activemq.artemis.logprocessor.annotation.Cause;
 import org.apache.activemq.artemis.logprocessor.annotation.LogBundle;
 import org.apache.activemq.artemis.logprocessor.annotation.LogMessage;
 
@@ -59,19 +58,19 @@ public interface ActiveMQJMSBridgeLogger {
    void bridgeNotStarted(String bridgeName);
 
    @LogMessage(id = 342006, value = "JMS Bridge {}, detected failure on bridge connection", level = LogMessage.Level.WARN)
-   void bridgeFailure(String bridgeName, @Cause Exception e);
+   void bridgeFailure(String bridgeName, Exception e);
 
    @LogMessage(id = 342009, value = "JMS Bridge {} failed to send + acknowledge batch, closing JMS objects", level = LogMessage.Level.WARN)
-   void bridgeAckError(String bridgeName, @Cause Exception e);
+   void bridgeAckError(String bridgeName, Exception e);
 
    @LogMessage(id = 342010, value = "Failed to connect JMS Bridge {}", level = LogMessage.Level.WARN)
-   void bridgeConnectError(String bridgeName, @Cause Exception e);
+   void bridgeConnectError(String bridgeName, Exception e);
 
    @LogMessage(id = 342011, value = "Transaction rolled back, retrying TX", level = LogMessage.Level.WARN)
-   void transactionRolledBack(@Cause Exception e);
+   void transactionRolledBack(Exception e);
 
    @LogMessage(id = 344001, value = "JMS Bridge {}, failed to start source connection", level = LogMessage.Level.ERROR)
-   void jmsBridgeSrcConnectError(String bridgeName, @Cause Exception e);
+   void jmsBridgeSrcConnectError(String bridgeName, Exception e);
 
    @LogMessage(id = 344002, value = "Failed to start JMS Bridge {}.  QoS Mode: {} requires a Transaction Manager, none found", level = LogMessage.Level.ERROR)
    void jmsBridgeTransactionManagerMissing(String bridgeName, QualityOfServiceMode qosMode);
diff --git a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/ActiveMQJMSServerBundle.java b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/ActiveMQJMSServerBundle.java
index 2caf27c0cc..c19791d302 100644
--- a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/ActiveMQJMSServerBundle.java
+++ b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/ActiveMQJMSServerBundle.java
@@ -20,7 +20,6 @@ import org.apache.activemq.artemis.api.core.ActiveMQAddressExistsException;
 import org.apache.activemq.artemis.api.core.ActiveMQIllegalStateException;
 import org.apache.activemq.artemis.api.core.ActiveMQInternalErrorException;
 import org.apache.activemq.artemis.logprocessor.CodeFactory;
-import org.apache.activemq.artemis.logprocessor.annotation.Cause;
 import org.apache.activemq.artemis.logprocessor.annotation.LogBundle;
 import org.apache.activemq.artemis.logprocessor.annotation.Message;
 
@@ -48,5 +47,5 @@ public interface ActiveMQJMSServerBundle {
    ActiveMQAddressExistsException cfBindingsExists(String name);
 
    @Message(id = 129007, value = "Error decoding password using codec instance")
-   ActiveMQIllegalStateException errorDecodingPassword(@Cause Exception e);
+   ActiveMQIllegalStateException errorDecodingPassword(Exception e);
 }
diff --git a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/ActiveMQJMSServerLogger.java b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/ActiveMQJMSServerLogger.java
index 3ceb87dee5..90f6e7967f 100644
--- a/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/ActiveMQJMSServerLogger.java
+++ b/artemis-jms-server/src/main/java/org/apache/activemq/artemis/jms/server/ActiveMQJMSServerLogger.java
@@ -18,7 +18,6 @@ package org.apache.activemq.artemis.jms.server;
 
 import org.apache.activemq.artemis.api.core.client.ClientSessionFactory;
 import org.apache.activemq.artemis.logprocessor.CodeFactory;
-import org.apache.activemq.artemis.logprocessor.annotation.Cause;
 import org.apache.activemq.artemis.logprocessor.annotation.LogBundle;
 import org.apache.activemq.artemis.logprocessor.annotation.LogMessage;
 import org.w3c.dom.Node;
@@ -49,24 +48,24 @@ public interface ActiveMQJMSServerLogger {
    void recoveryConnectFailed(String s);
 
    @LogMessage(id = 122011, value = "error unbinding {} from Registry", level = LogMessage.Level.WARN)
-   void bindingsUnbindError(String key, @Cause Exception e);
+   void bindingsUnbindError(String key, Exception e);
 
    @LogMessage(id = 122012, value = "JMS Server Manager error", level = LogMessage.Level.WARN)
-   void jmsServerError(@Cause Exception e);
+   void jmsServerError(Exception e);
 
    @LogMessage(id = 122013, value = "Error in XA Recovery recover", level = LogMessage.Level.WARN)
-   void xaRecoverError(@Cause Exception e);
+   void xaRecoverError(Exception e);
 
    @LogMessage(id = 122014, value = "Notified of connection failure in xa recovery connectionFactory for provider {} will attempt reconnect on next pass",
       level = LogMessage.Level.WARN)
-   void xaRecoverConnectionError(ClientSessionFactory csf, @Cause Exception e);
+   void xaRecoverConnectionError(ClientSessionFactory csf, Exception e);
 
    @LogMessage(id = 122016, value = "Error in XA Recovery", level = LogMessage.Level.DEBUG)
-   void xaRecoveryError(@Cause Exception e);
+   void xaRecoveryError(Exception e);
 
    @LogMessage(id = 122017, value = "Tried to correct invalid \"host\" value \"0.0.0.0\" for \"{}\" connector, but received an exception.",
       level = LogMessage.Level.WARN)
-   void failedToCorrectHost(String name, @Cause Exception e);
+   void failedToCorrectHost(String name, Exception e);
 
    @LogMessage(id = 122018,
       value = "Failed to send notification: {}",
@@ -76,7 +75,7 @@ public interface ActiveMQJMSServerLogger {
    @LogMessage(id = 122019,
       value = "Unable to deactivate server",
       level = LogMessage.Level.WARN)
-   void failedToDeactivateServer(@Cause Exception e);
+   void failedToDeactivateServer(Exception e);
 
    @LogMessage(id = 123000, value = "JMS Server Manager Running cached command for {}." + "(In the event of failover after failback has occurred, this message may be output multiple times.)",
       level = LogMessage.Level.DEBUG)
@@ -86,5 +85,5 @@ public interface ActiveMQJMSServerLogger {
    void jmsConfigMissingKey(Node e);
 
    @LogMessage(id = 124002, value = "Failed to start JMS deployer", level = LogMessage.Level.ERROR)
-   void jmsDeployerStartError(@Cause Exception e);
+   void jmsDeployerStartError(Exception e);
 }
diff --git a/artemis-journal/src/main/java/org/apache/activemq/artemis/journal/ActiveMQJournalLogger.java b/artemis-journal/src/main/java/org/apache/activemq/artemis/journal/ActiveMQJournalLogger.java
index 0d5879d414..db6ce55967 100644
--- a/artemis-journal/src/main/java/org/apache/activemq/artemis/journal/ActiveMQJournalLogger.java
+++ b/artemis-journal/src/main/java/org/apache/activemq/artemis/journal/ActiveMQJournalLogger.java
@@ -18,7 +18,6 @@ package org.apache.activemq.artemis.journal;
 
 import org.apache.activemq.artemis.core.journal.impl.JournalFile;
 import org.apache.activemq.artemis.logprocessor.CodeFactory;
-import org.apache.activemq.artemis.logprocessor.annotation.Cause;
 import org.apache.activemq.artemis.logprocessor.annotation.LogBundle;
 import org.apache.activemq.artemis.logprocessor.annotation.LogMessage;
 
@@ -130,43 +129,43 @@ public interface ActiveMQJournalLogger {
    void errorOnIOCallback(String errorMessage);
 
    @LogMessage(id = 142022, value = "Timed out on AIO poller shutdown", level = LogMessage.Level.WARN)
-   void timeoutOnPollerShutdown(@Cause Exception e);
+   void timeoutOnPollerShutdown(Exception e);
 
    @LogMessage(id = 142023, value = "Executor on file {} couldn't complete its tasks in 60 seconds.", level = LogMessage.Level.WARN)
-   void couldNotCompleteTask(String name, @Cause Exception e);
+   void couldNotCompleteTask(String name, Exception e);
 
    @LogMessage(id = 142024, value = "Error completing callback", level = LogMessage.Level.WARN)
-   void errorCompletingCallback(@Cause Throwable e);
+   void errorCompletingCallback(Throwable e);
 
    @LogMessage(id = 142025, value = "Error calling onError callback", level = LogMessage.Level.WARN)
-   void errorCallingErrorCallback(@Cause Throwable e);
+   void errorCallingErrorCallback(Throwable e);
 
    @LogMessage(id = 142026, value = "Timed out on AIO writer shutdown", level = LogMessage.Level.WARN)
-   void timeoutOnWriterShutdown(@Cause Throwable e);
+   void timeoutOnWriterShutdown(Throwable e);
 
    @LogMessage(id = 142027, value = "Error on writing data! {} code - {}", level = LogMessage.Level.WARN)
-   void errorWritingData(String errorMessage, int errorCode, @Cause Throwable e);
+   void errorWritingData(String errorMessage, int errorCode, Throwable e);
 
    @LogMessage(id = 142028, value = "Error replaying pending commands after compacting", level = LogMessage.Level.WARN)
-   void errorReplayingCommands(@Cause Throwable e);
+   void errorReplayingCommands(Throwable e);
 
    @LogMessage(id = 142029, value = "Error closing file", level = LogMessage.Level.WARN)
-   void errorClosingFile(@Cause Throwable e);
+   void errorClosingFile(Throwable e);
 
    @LogMessage(id = 142030, value = "Could not open a file in 60 Seconds", level = LogMessage.Level.WARN)
-   void errorOpeningFile(@Cause Throwable e);
+   void errorOpeningFile(Throwable e);
 
    @LogMessage(id = 142031, value = "Error retrieving ID part of the file name {}", level = LogMessage.Level.WARN)
-   void errorRetrievingID(String fileName, @Cause Throwable e);
+   void errorRetrievingID(String fileName, Throwable e);
 
    @LogMessage(id = 142032, value = "Error reading journal file", level = LogMessage.Level.WARN)
-   void errorReadingFile(@Cause Throwable e);
+   void errorReadingFile(Throwable e);
 
    @LogMessage(id = 142033, value = "Error reinitializing file {}", level = LogMessage.Level.WARN)
-   void errorReinitializingFile(JournalFile file, @Cause Throwable e);
+   void errorReinitializingFile(JournalFile file, Throwable e);
 
    @LogMessage(id = 142034, value = "Exception on submitting write", level = LogMessage.Level.WARN)
-   void errorSubmittingWrite(@Cause Throwable e);
+   void errorSubmittingWrite(Throwable e);
 
    @LogMessage(id = 142035, value = "Could not stop journal append executor after 60 seconds", level = LogMessage.Level.WARN)
    void couldNotStopJournalAppendExecutor();
@@ -175,19 +174,19 @@ public interface ActiveMQJournalLogger {
    void errorDeletingFile(Object e);
 
    @LogMessage(id = 144001, value = "Error starting poller", level = LogMessage.Level.ERROR)
-   void errorStartingPoller(@Cause Exception e);
+   void errorStartingPoller(Exception e);
 
    @LogMessage(id = 144002, value = "Error pushing opened file", level = LogMessage.Level.ERROR)
-   void errorPushingFile(@Cause Exception e);
+   void errorPushingFile(Exception e);
 
    @LogMessage(id = 144003, value = "Error compacting", level = LogMessage.Level.ERROR)
-   void errorCompacting(@Cause Throwable e);
+   void errorCompacting(Throwable e);
 
    @LogMessage(id = 144004, value = "Error scheduling compacting", level = LogMessage.Level.ERROR)
-   void errorSchedulingCompacting(@Cause Throwable e);
+   void errorSchedulingCompacting(Throwable e);
 
    @LogMessage(id = 144005, value = "Failed to performance blast", level = LogMessage.Level.ERROR)
-   void failedToPerfBlast(@Cause Throwable e);
+   void failedToPerfBlast(Throwable e);
 
    @LogMessage(id = 144006, value = "IOError code {}, {}", level = LogMessage.Level.ERROR)
    void ioError(int errorCode, String errorMessage);
@@ -202,6 +201,6 @@ public interface ActiveMQJournalLogger {
    void cantOpenFileTimeout(long timeout);
 
    @LogMessage(id = 144010, value = "Critical IO Exception happened: {}", level = LogMessage.Level.WARN)
-   void criticalIO(String message, @Cause Exception error);
+   void criticalIO(String message, Exception error);
 
 }
diff --git a/artemis-log-processor/src/main/java/org/apache/activemq/artemis/logprocessor/annotation/Cause.java b/artemis-log-processor/src/main/java/org/apache/activemq/artemis/logprocessor/annotation/Cause.java
deleted file mode 100644
index a0751d402e..0000000000
--- a/artemis-log-processor/src/main/java/org/apache/activemq/artemis/logprocessor/annotation/Cause.java
+++ /dev/null
@@ -1,30 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements. See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License. You may obtain a copy of the License at
- * <p>
- * http://www.apache.org/licenses/LICENSE-2.0
- * <p>
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.activemq.artemis.logprocessor.annotation;
-
-import java.lang.annotation.Retention;
-import java.lang.annotation.RetentionPolicy;
-import java.lang.annotation.Target;
-
-import static java.lang.annotation.ElementType.PARAMETER;
-
-@Target(PARAMETER)
-@Retention(RetentionPolicy.SOURCE)
-public @interface Cause {
-
-}
diff --git a/artemis-protocols/artemis-mqtt-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/mqtt/MQTTLogger.java b/artemis-protocols/artemis-mqtt-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/mqtt/MQTTLogger.java
index 03a6a0014b..655dc2b1ed 100644
--- a/artemis-protocols/artemis-mqtt-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/mqtt/MQTTLogger.java
+++ b/artemis-protocols/artemis-mqtt-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/mqtt/MQTTLogger.java
@@ -19,7 +19,6 @@ package org.apache.activemq.artemis.core.protocol.mqtt;
 
 import org.apache.activemq.artemis.core.server.MessageReference;
 import org.apache.activemq.artemis.logprocessor.CodeFactory;
-import org.apache.activemq.artemis.logprocessor.annotation.Cause;
 import org.apache.activemq.artemis.logprocessor.annotation.LogBundle;
 import org.apache.activemq.artemis.logprocessor.annotation.LogMessage;
 /**
@@ -43,29 +42,29 @@ public interface MQTTLogger {
    MQTTLogger LOGGER = CodeFactory.getCodeClass(MQTTLogger.class, MQTTLogger.class.getPackage().getName());
 
    @LogMessage(id = 832000, value = "Unable to send message: {}", level = LogMessage.Level.WARN)
-   void unableToSendMessage(MessageReference message, @Cause Exception e);
+   void unableToSendMessage(MessageReference message, Exception e);
 
    @LogMessage(id = 832001, value = "MQTT client({}) attempted to ack already ack'd message: ", level = LogMessage.Level.WARN)
-   void failedToAckMessage(String clientId, @Cause Exception e);
+   void failedToAckMessage(String clientId, Exception e);
 
    @LogMessage(id = 834000, value = "Error removing subscription.", level = LogMessage.Level.ERROR)
-   void errorRemovingSubscription(@Cause Exception e);
+   void errorRemovingSubscription(Exception e);
 
    @LogMessage(id = 834001, value = "Error disconnecting client.", level = LogMessage.Level.ERROR)
-   void errorDisconnectingClient(@Cause Exception e);
+   void errorDisconnectingClient(Exception e);
 
    @LogMessage(id = 834002, value = "Error processing control packet: {}", level = LogMessage.Level.ERROR)
-   void errorProcessingControlPacket(String packet, @Cause Exception e);
+   void errorProcessingControlPacket(String packet, Exception e);
 
    @LogMessage(id = 834003, value = "Error sending will message.", level = LogMessage.Level.ERROR)
-   void errorSendingWillMessage(@Cause Exception e);
+   void errorSendingWillMessage(Exception e);
 
    @LogMessage(id = 834004, value = "Error disconnecting consumer.", level = LogMessage.Level.ERROR)
-   void errorDisconnectingConsumer(@Cause Exception e);
+   void errorDisconnectingConsumer(Exception e);
 
    @LogMessage(id = 834005, value = "Failed to cast property {}.", level = LogMessage.Level.ERROR)
    void failedToCastProperty(String property);
 
    @LogMessage(id = 834006, value = "Failed to publish MQTT message: {}.", level = LogMessage.Level.ERROR)
-   void failedToPublishMqttMessage(String exceptionMessage, @Cause Throwable t);
+   void failedToPublishMqttMessage(String exceptionMessage, Throwable t);
 }
\ No newline at end of file
diff --git a/artemis-protocols/artemis-stomp-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/stomp/ActiveMQStompProtocolLogger.java b/artemis-protocols/artemis-stomp-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/stomp/ActiveMQStompProtocolLogger.java
index e1638e38fd..cd2ca5f4a6 100644
--- a/artemis-protocols/artemis-stomp-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/stomp/ActiveMQStompProtocolLogger.java
+++ b/artemis-protocols/artemis-stomp-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/stomp/ActiveMQStompProtocolLogger.java
@@ -17,7 +17,6 @@
 package org.apache.activemq.artemis.core.protocol.stomp;
 
 import org.apache.activemq.artemis.logprocessor.CodeFactory;
-import org.apache.activemq.artemis.logprocessor.annotation.Cause;
 import org.apache.activemq.artemis.logprocessor.annotation.LogBundle;
 import org.apache.activemq.artemis.logprocessor.annotation.LogMessage;
 
@@ -48,5 +47,5 @@ public interface ActiveMQStompProtocolLogger {
    void sentErrorToClient(String address, String message);
 
    @LogMessage(id = 334023, value = "Unable to send frame {}", level = LogMessage.Level.ERROR)
-   void errorSendingFrame(StompFrame frame, @Cause Exception e);
+   void errorSendingFrame(StompFrame frame, Exception e);
 }
diff --git a/artemis-protocols/artemis-stomp-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/stomp/ActiveMQStompProtocolMessageBundle.java b/artemis-protocols/artemis-stomp-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/stomp/ActiveMQStompProtocolMessageBundle.java
index a5f5bf4977..ebd82bb85a 100644
--- a/artemis-protocols/artemis-stomp-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/stomp/ActiveMQStompProtocolMessageBundle.java
+++ b/artemis-protocols/artemis-stomp-protocol/src/main/java/org/apache/activemq/artemis/core/protocol/stomp/ActiveMQStompProtocolMessageBundle.java
@@ -17,7 +17,6 @@
 package org.apache.activemq.artemis.core.protocol.stomp;
 
 import org.apache.activemq.artemis.logprocessor.CodeFactory;
-import org.apache.activemq.artemis.logprocessor.annotation.Cause;
 import org.apache.activemq.artemis.logprocessor.annotation.LogBundle;
 import org.apache.activemq.artemis.logprocessor.annotation.Message;
 
@@ -64,34 +63,34 @@ public interface ActiveMQStompProtocolMessageBundle {
    ActiveMQStompException connectionNotEstablished();
 
    @Message(id = 339009, value = "Exception getting session")
-   ActiveMQStompException errorGetSession(@Cause Exception e);
+   ActiveMQStompException errorGetSession(Exception e);
 
    @Message(id = 339010, value = "Connection is not valid.")
    ActiveMQStompException invalidConnection();
 
    @Message(id = 339011, value = "Error sending message {}")
-   ActiveMQStompException errorSendMessage(org.apache.activemq.artemis.api.core.Message message, @Cause Exception e);
+   ActiveMQStompException errorSendMessage(org.apache.activemq.artemis.api.core.Message message, Exception e);
 
    @Message(id = 339012, value = "Error beginning a transaction {}")
-   ActiveMQStompException errorBeginTx(String txID, @Cause Exception e);
+   ActiveMQStompException errorBeginTx(String txID, Exception e);
 
    @Message(id = 339013, value = "Error committing {}")
-   ActiveMQStompException errorCommitTx(String txID, @Cause Exception e);
+   ActiveMQStompException errorCommitTx(String txID, Exception e);
 
    @Message(id = 339014, value = "Error aborting {}")
-   ActiveMQStompException errorAbortTx(String txID, @Cause Exception e);
+   ActiveMQStompException errorAbortTx(String txID, Exception e);
 
    @Message(id = 339015, value = "Client must set destination or id header to a SUBSCRIBE command")
    ActiveMQStompException noDestination();
 
    @Message(id = 339016, value = "Error creating subscription {}")
-   ActiveMQStompException errorCreatingSubscription(String subscriptionID, @Cause Exception e);
+   ActiveMQStompException errorCreatingSubscription(String subscriptionID, Exception e);
 
    @Message(id = 339017, value = "Error unsubscribing {}")
-   ActiveMQStompException errorUnsubscribing(String subscriptionID, @Cause Exception e);
+   ActiveMQStompException errorUnsubscribing(String subscriptionID, Exception e);
 
    @Message(id = 339018, value = "Error acknowledging message {}")
-   ActiveMQStompException errorAck(String messageID, @Cause Exception e);
+   ActiveMQStompException errorAck(String messageID, Exception e);
 
    @Message(id = 339019, value = "Invalid char sequence: two consecutive CRs.")
    ActiveMQStompException invalidTwoCRs();
@@ -130,7 +129,7 @@ public interface ActiveMQStompProtocolMessageBundle {
    ActiveMQStompException needTxIDHeader();
 
    @Message(id = 339031, value = "Error handling send")
-   ActiveMQStompException errorHandleSend(@Cause Exception e);
+   ActiveMQStompException errorHandleSend(Exception e);
 
    @Message(id = 339032, value = "Need a transaction id to begin")
    ActiveMQStompException beginTxNoID();
diff --git a/artemis-ra/src/main/java/org/apache/activemq/artemis/ra/ActiveMQRABundle.java b/artemis-ra/src/main/java/org/apache/activemq/artemis/ra/ActiveMQRABundle.java
index f7b91ba798..3543863ab7 100644
--- a/artemis-ra/src/main/java/org/apache/activemq/artemis/ra/ActiveMQRABundle.java
+++ b/artemis-ra/src/main/java/org/apache/activemq/artemis/ra/ActiveMQRABundle.java
@@ -22,7 +22,6 @@ import javax.resource.NotSupportedException;
 
 import org.apache.activemq.artemis.api.core.ActiveMQIllegalStateException;
 import org.apache.activemq.artemis.logprocessor.CodeFactory;
-import org.apache.activemq.artemis.logprocessor.annotation.Cause;
 import org.apache.activemq.artemis.logprocessor.annotation.LogBundle;
 import org.apache.activemq.artemis.logprocessor.annotation.Message;
 
@@ -40,7 +39,7 @@ public interface ActiveMQRABundle {
    ActiveMQRABundle BUNDLE = CodeFactory.getCodeClass(ActiveMQRABundle.class);
 
    @Message(id = 159000, value = "Error decoding password using codec instance")
-   ActiveMQIllegalStateException errorDecodingPassword(@Cause Exception e);
+   ActiveMQIllegalStateException errorDecodingPassword(Exception e);
 
    @Message(id = 159001, value = "MDB cannot be deployed as it has no Activation Spec. Please provide an Activation!")
    NotSupportedException noActivationSpec();
diff --git a/artemis-ra/src/main/java/org/apache/activemq/artemis/ra/ActiveMQRALogger.java b/artemis-ra/src/main/java/org/apache/activemq/artemis/ra/ActiveMQRALogger.java
index fe65766839..f69db0e17c 100644
--- a/artemis-ra/src/main/java/org/apache/activemq/artemis/ra/ActiveMQRALogger.java
+++ b/artemis-ra/src/main/java/org/apache/activemq/artemis/ra/ActiveMQRALogger.java
@@ -17,7 +17,6 @@
 package org.apache.activemq.artemis.ra;
 
 import org.apache.activemq.artemis.logprocessor.CodeFactory;
-import org.apache.activemq.artemis.logprocessor.annotation.Cause;
 import org.apache.activemq.artemis.logprocessor.annotation.LogBundle;
 import org.apache.activemq.artemis.logprocessor.annotation.LogMessage;
 import org.apache.activemq.artemis.logprocessor.annotation.Message;
@@ -63,49 +62,49 @@ public interface ActiveMQRALogger {
    void resourceAdaptorStarted();
 
    @LogMessage(id = 152001, value = "problem resetting xa session after failure", level = LogMessage.Level.WARN)
-   void problemResettingXASession(@Cause Throwable t);
+   void problemResettingXASession(Throwable t);
 
    @LogMessage(id = 152002, value = "Unable to roll local transaction back", level = LogMessage.Level.WARN)
    void unableToRollbackTX();
 
    @LogMessage(id = 152003, value = "unable to reset session after failure, we will place the MDB Inflow now in setup mode for activation={}", level = LogMessage.Level.WARN)
-   void unableToResetSession(String spec, @Cause Exception e);
+   void unableToResetSession(String spec, Exception e);
 
    @LogMessage(id = 152004, value = "Handling JMS exception failure", level = LogMessage.Level.WARN)
-   void handlingJMSFailure(@Cause Exception e);
+   void handlingJMSFailure(Exception e);
 
    @LogMessage(id = 152005, value = "Failure in broker activation {}", level = LogMessage.Level.WARN)
-   void failureInActivation(ActiveMQActivationSpec spec, @Cause Throwable t);
+   void failureInActivation(ActiveMQActivationSpec spec, Throwable t);
 
    @LogMessage(id = 152006, value = "Unable to call after delivery", level = LogMessage.Level.WARN)
-   void unableToCallAfterDelivery(@Cause Exception e);
+   void unableToCallAfterDelivery(Exception e);
 
    @LogMessage(id = 152007, value = "Thread {} could not be finished", level = LogMessage.Level.WARN)
    void threadCouldNotFinish(String thread);
 
    @LogMessage(id = 152008, value = "Error interrupting handler on endpoint {} handler = {}", level = LogMessage.Level.WARN)
-   void errorInterruptingHandler(String endpoint, String handler, @Cause Throwable cause);
+   void errorInterruptingHandler(String endpoint, String handler, Throwable cause);
 
    @LogMessage(id = 152009, value = "Unable to validate properties", level = LogMessage.Level.WARN)
-   void unableToValidateProperties(@Cause Exception e);
+   void unableToValidateProperties(Exception e);
 
    @LogMessage(id = 152010, value = "Unable to clear the transaction", level = LogMessage.Level.WARN)
-   void unableToClearTheTransaction(@Cause Exception e);
+   void unableToClearTheTransaction(Exception e);
 
    @LogMessage(id = 152011, value = "Unable to close the factory", level = LogMessage.Level.WARN)
-   void unableToCloseFactory(@Cause Throwable e);
+   void unableToCloseFactory(Throwable e);
 
    @LogMessage(id = 154000, value = "Error while creating object Reference.", level = LogMessage.Level.ERROR)
-   void errorCreatingReference(@Cause Exception e);
+   void errorCreatingReference(Exception e);
 
    @LogMessage(id = 154001, value = "Unable to stop resource adapter.", level = LogMessage.Level.ERROR)
-   void errorStoppingRA(@Cause Exception e);
+   void errorStoppingRA(Exception e);
 
    @LogMessage(id = 154003, value = "Unable to reconnect {}", level = LogMessage.Level.ERROR)
-   void errorReconnecting(ActiveMQActivationSpec spec, @Cause Throwable t);
+   void errorReconnecting(ActiveMQActivationSpec spec, Throwable t);
 
    @LogMessage(id = 154004, value = "Failed to deliver message", level = LogMessage.Level.ERROR)
-   void errorDeliveringMessage(@Cause Throwable t);
+   void errorDeliveringMessage(Throwable t);
 
    @LogMessage(id = 153001, value = "using different ActiveMQRAConnectionFactory", level = LogMessage.Level.DEBUG)
    void warnDifferentConnectionfactory();
diff --git a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/ActiveMQRestLogger.java b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/ActiveMQRestLogger.java
index 77fd74ddf5..1fb688e0b6 100644
--- a/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/ActiveMQRestLogger.java
+++ b/artemis-rest/src/main/java/org/apache/activemq/artemis/rest/ActiveMQRestLogger.java
@@ -19,7 +19,6 @@ package org.apache.activemq.artemis.rest;
 import org.apache.activemq.artemis.api.core.ActiveMQException;
 import org.apache.activemq.artemis.logprocessor.CodeFactory;
 import org.apache.activemq.artemis.rest.queue.push.xml.XmlLink;
-import org.apache.activemq.artemis.logprocessor.annotation.Cause;
 import org.apache.activemq.artemis.logprocessor.annotation.LogBundle;
 import org.apache.activemq.artemis.logprocessor.annotation.LogMessage;
 
@@ -48,23 +47,23 @@ public interface ActiveMQRestLogger {
    void shutdownRestSubscription(String id);
 
    @LogMessage(id = 182002, value = "Failed to push message to {}", level = LogMessage.Level.WARN)
-   void failedToPushMessageToUri(String uri, @Cause Exception e);
+   void failedToPushMessageToUri(String uri, Exception e);
 
    @LogMessage(id = 182003, value = "Failed to build Message from object", level = LogMessage.Level.WARN)
-   void failedToBuildMessageFromObject(@Cause Exception e);
+   void failedToBuildMessageFromObject(Exception e);
 
    @LogMessage(id = 182004, value = "REST configuration parameter '{}' is deprecated. Use '{}' instead.", level = LogMessage.Level.WARN)
    void deprecatedConfiguration(String oldConfigParameter, String newConfigParameter);
 
    @LogMessage(id = 184000, value = "Failed to load push store {}, it is probably corrupted", level = LogMessage.Level.ERROR)
-   void errorLoadingStore(String name, @Cause Exception e);
+   void errorLoadingStore(String name, Exception e);
 
    @LogMessage(id = 184001, value = "Error updating store", level = LogMessage.Level.ERROR)
-   void errorUpdatingStore(@Cause Exception e);
+   void errorUpdatingStore(Exception e);
 
    @LogMessage(id = 184002, value = "Failed to push message to {} disabling push registration...", level = LogMessage.Level.ERROR)
    void errorPushingMessage(XmlLink link);
 
    @LogMessage(id = 184003, value = "Error deleting Subscriber queue", level = LogMessage.Level.ERROR)
-   void errorDeletingSubscriberQueue(@Cause ActiveMQException e);
+   void errorDeletingSubscriberQueue(ActiveMQException e);
 }
diff --git a/artemis-server-osgi/src/main/java/org/apache/activemq/artemis/osgi/ActiveMQOsgiLogger.java b/artemis-server-osgi/src/main/java/org/apache/activemq/artemis/osgi/ActiveMQOsgiLogger.java
index 52e88484f2..68abac3ccf 100644
--- a/artemis-server-osgi/src/main/java/org/apache/activemq/artemis/osgi/ActiveMQOsgiLogger.java
+++ b/artemis-server-osgi/src/main/java/org/apache/activemq/artemis/osgi/ActiveMQOsgiLogger.java
@@ -17,7 +17,6 @@
 package org.apache.activemq.artemis.osgi;
 
 import org.apache.activemq.artemis.logprocessor.CodeFactory;
-import org.apache.activemq.artemis.logprocessor.annotation.Cause;
 import org.apache.activemq.artemis.logprocessor.annotation.LogBundle;
 import org.apache.activemq.artemis.logprocessor.annotation.LogMessage;
 
@@ -42,12 +41,12 @@ public interface ActiveMQOsgiLogger {
    void protocolWasRemovedForBroker(String protocol, String name, String message);
 
    @LogMessage(id = 582000, value = "Error starting broker: {}", level = LogMessage.Level.WARN)
-   void errorStartingBroker(String name, @Cause Exception e);
+   void errorStartingBroker(String name, Exception e);
 
    @LogMessage(id = 582001, value = "Error stopping broker: {}", level = LogMessage.Level.WARN)
-   void errorStoppingBroker(String name, @Cause Exception e);
+   void errorStoppingBroker(String name, Exception e);
 
    @LogMessage(id = 582002, value = "Error getting dataSource provider infos.", level = LogMessage.Level.WARN)
-   void errorGettingDataSourceProviderInfo(@Cause Exception e);
+   void errorGettingDataSourceProviderInfo(Exception e);
 
 }
\ No newline at end of file
diff --git a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/ActiveMQMessageBundle.java b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/ActiveMQMessageBundle.java
index 47c32cc542..61c85960d8 100644
--- a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/ActiveMQMessageBundle.java
+++ b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/ActiveMQMessageBundle.java
@@ -55,7 +55,6 @@ import org.apache.activemq.artemis.core.postoffice.Binding;
 import org.apache.activemq.artemis.core.protocol.core.impl.wireformat.ReplicationSyncFileMessage;
 import org.apache.activemq.artemis.core.security.CheckType;
 import org.apache.activemq.artemis.logprocessor.CodeFactory;
-import org.apache.activemq.artemis.logprocessor.annotation.Cause;
 import org.apache.activemq.artemis.logprocessor.annotation.LogBundle;
 import org.apache.activemq.artemis.logprocessor.annotation.Message;
 
@@ -95,7 +94,7 @@ public interface ActiveMQMessageBundle {
    ActiveMQInternalErrorException notJournalImpl();
 
    @Message(id = 229007, value = "unhandled error during replication")
-   ActiveMQInternalErrorException replicationUnhandledError(@Cause Exception e);
+   ActiveMQInternalErrorException replicationUnhandledError(Exception e);
 
    @Message(id = 229008, value = "Live Node contains more journals than the backup node. Probably a version match error")
    ActiveMQInternalErrorException replicationTooManyJournals();
@@ -131,7 +130,7 @@ public interface ActiveMQMessageBundle {
    ActiveMQQueueExistsException queueAlreadyExists(SimpleString queueName, SimpleString addressName);
 
    @Message(id = 229020, value = "Invalid filter: {}")
-   ActiveMQInvalidFilterExpressionException invalidFilter(SimpleString filter, @Cause Throwable e);
+   ActiveMQInvalidFilterExpressionException invalidFilter(SimpleString filter, Throwable e);
 
    @Message(id = 229021, value = "MessageId was not assigned to Message")
    ActiveMQIllegalStateException messageIdNotAssigned();
@@ -287,7 +286,7 @@ public interface ActiveMQMessageBundle {
    IllegalArgumentException nullPassword();
 
    @Message(id = 229074, value = "Error instantiating transformer class {}")
-   IllegalArgumentException errorCreatingTransformerClass(String transformerClassName, @Cause Exception e);
+   IllegalArgumentException errorCreatingTransformerClass(String transformerClassName, Exception e);
 
    @Message(id = 229075, value = "method autoEncode doesn't know how to convert {} yet")
    IllegalArgumentException autoConvertError(Class<? extends Object> aClass);
@@ -488,7 +487,7 @@ public interface ActiveMQMessageBundle {
    IllegalArgumentException failedToParseJson(String json);
 
    @Message(id = 229230, value = "Failed to bind acceptor {} to {}")
-   IllegalStateException failedToBind(String acceptor, String hostPort, @Cause Exception e);
+   IllegalStateException failedToBind(String acceptor, String hostPort, Exception e);
 
    @Message(id = 229231, value = "Divert Does Not Exist: {}")
    ActiveMQDivertDoesNotExistException divertDoesNotExist(String divert);
@@ -527,5 +526,5 @@ public interface ActiveMQMessageBundle {
    ActiveMQTimeoutException embeddedWebServerRestartTimeout(long timeout);
 
    @Message(id = 229243, value = "Embedded web server restart failed")
-   ActiveMQException embeddedWebServerRestartFailed(@Cause Exception e);
+   ActiveMQException embeddedWebServerRestartFailed(Exception e);
 }
diff --git a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/ActiveMQServerLogger.java b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/ActiveMQServerLogger.java
index 23f9e2dcc0..061f8e2c0e 100644
--- a/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/ActiveMQServerLogger.java
+++ b/artemis-server/src/main/java/org/apache/activemq/artemis/core/server/ActiveMQServerLogger.java
@@ -49,7 +49,6 @@ import org.apache.activemq.artemis.core.server.impl.ActiveMQServerImpl;
 import org.apache.activemq.artemis.core.server.impl.ServerSessionImpl;
 import org.apache.activemq.artemis.core.server.management.Notification;
 import org.apache.activemq.artemis.logprocessor.CodeFactory;
-import org.apache.activemq.artemis.logprocessor.annotation.Cause;
 import org.apache.activemq.artemis.logprocessor.annotation.LogBundle;
 import org.apache.activemq.artemis.logprocessor.annotation.LogMessage;
 import org.apache.activemq.artemis.spi.core.remoting.Connection;
@@ -148,10 +147,10 @@ public interface ActiveMQServerLogger {
    void errorRemovingConnection();
 
    @LogMessage(id = 221022, value = "unable to start connector service: {}", level = LogMessage.Level.INFO)
-   void errorStartingConnectorService(String name, @Cause Throwable e);
+   void errorStartingConnectorService(String name, Throwable e);
 
    @LogMessage(id = 221023, value = "unable to stop connector service: {}", level = LogMessage.Level.INFO)
-   void errorStoppingConnectorService(String name, @Cause Throwable e);
+   void errorStoppingConnectorService(String name, Throwable e);
 
    @LogMessage(id = 221024, value = "Backup server {} is synchronized with live server, nodeID={}.", level = LogMessage.Level.INFO)
    void backupServerSynchronized(ActiveMQServerImpl server, String liveID);
@@ -303,10 +302,10 @@ public interface ActiveMQServerLogger {
    void failingOverBasedOnQuorumVoteResults();
 
    @LogMessage(id = 221072, value = "Can't find roles for the subject.", level = LogMessage.Level.INFO)
-   void failedToFindRolesForTheSubject(@Cause Exception e);
+   void failedToFindRolesForTheSubject(Exception e);
 
    @LogMessage(id = 221073, value = "Can't add role principal.", level = LogMessage.Level.INFO)
-   void failedAddRolePrincipal(@Cause Exception e);
+   void failedAddRolePrincipal(Exception e);
 
    @LogMessage(id = 221074, value = "Debug started : size = {} bytes, messages = {}", level = LogMessage.Level.INFO)
    void debugStarted(Long globalSizeBytes, Long numberOfMessages);
@@ -351,7 +350,7 @@ public interface ActiveMQServerLogger {
    void serverFinalisedWIthoutBeingSTopped();
 
    @LogMessage(id = 222001, value = "Error closing sessions while stopping server", level = LogMessage.Level.WARN)
-   void errorClosingSessionsWhileStoppingServer(@Cause Exception e);
+   void errorClosingSessionsWhileStoppingServer(Exception e);
 
    @LogMessage(id = 222002, value = "Timed out waiting for pool to terminate {}. Interrupting all its threads!", level = LogMessage.Level.WARN)
    void timedOutStoppingThreadpool(ExecutorService service);
@@ -369,25 +368,25 @@ public interface ActiveMQServerLogger {
    void clusterSecurityRisk();
 
    @LogMessage(id = 222008, value = "unable to restart server, please kill and restart manually", level = LogMessage.Level.WARN)
-   void serverRestartWarning(@Cause Exception e);
+   void serverRestartWarning(Exception e);
 
    @LogMessage(id = 222009, value = "Unable to announce backup for replication. Trying to stop the server.", level = LogMessage.Level.WARN)
-   void replicationStartProblem(@Cause Exception e);
+   void replicationStartProblem(Exception e);
 
    @LogMessage(id = 222010, value = "Critical IO Error, shutting down the server. file={}, message={}", level = LogMessage.Level.ERROR)
-   void ioCriticalIOError(String message, String file, @Cause Throwable code);
+   void ioCriticalIOError(String message, String file, Throwable code);
 
    @LogMessage(id = 222011, value = "Error stopping server", level = LogMessage.Level.WARN)
-   void errorStoppingServer(@Cause Exception e);
+   void errorStoppingServer(Exception e);
 
    @LogMessage(id = 222012, value = "Timed out waiting for backup activation to exit", level = LogMessage.Level.WARN)
    void backupActivationProblem();
 
    @LogMessage(id = 222013, value = "Error when trying to start replication", level = LogMessage.Level.WARN)
-   void errorStartingReplication(@Cause Exception e);
+   void errorStartingReplication(Exception e);
 
    @LogMessage(id = 222014, value = "Error when trying to stop replication", level = LogMessage.Level.WARN)
-   void errorStoppingReplication(@Cause Exception e);
+   void errorStoppingReplication(Exception e);
 
    @LogMessage(id = 222016, value = "Cannot deploy a connector with no name specified.", level = LogMessage.Level.WARN)
    void connectorWithNoName();
@@ -402,25 +401,25 @@ public interface ActiveMQServerLogger {
    void discoveryGroupAlreadyDeployed(String name);
 
    @LogMessage(id = 222020, value = "error scanning for URL's", level = LogMessage.Level.WARN)
-   void errorScanningURLs(@Cause Exception e);
+   void errorScanningURLs(Exception e);
 
    @LogMessage(id = 222021, value = "problem undeploying {}", level = LogMessage.Level.WARN)
-   void problemUndeployingNode(Node node, @Cause Exception e);
+   void problemUndeployingNode(Node node, Exception e);
 
    @LogMessage(id = 222022, value = "Timed out waiting for paging cursor to stop {}", level = LogMessage.Level.WARN)
    void timedOutStoppingPagingCursor(Executor executor);
 
    @LogMessage(id = 222023, value = "problem cleaning page address {}", level = LogMessage.Level.WARN)
-   void problemCleaningPageAddress(SimpleString address, @Cause Exception e);
+   void problemCleaningPageAddress(SimpleString address, Exception e);
 
    @LogMessage(id = 222024, value = "Could not complete operations on IO context {}", level = LogMessage.Level.WARN)
    void problemCompletingOperations(OperationContext e);
 
    @LogMessage(id = 222025, value = "Problem cleaning page subscription counter", level = LogMessage.Level.WARN)
-   void problemCleaningPagesubscriptionCounter(@Cause Exception e);
+   void problemCleaningPagesubscriptionCounter(Exception e);
 
    @LogMessage(id = 222026, value = "Error on cleaning up cursor pages", level = LogMessage.Level.WARN)
-   void problemCleaningCursorPages(@Cause Exception e);
+   void problemCleaningCursorPages(Exception e);
 
    @LogMessage(id = 222027, value = "Timed out flushing executors for paging cursor to stop {}", level = LogMessage.Level.WARN)
    void timedOutFlushingExecutorsPagingCursor(PageSubscription pageSubscription);
@@ -435,16 +434,16 @@ public interface ActiveMQServerLogger {
    void pageInvalid(String fileName, String name);
 
    @LogMessage(id = 222031, value = "Error while deleting page file", level = LogMessage.Level.WARN)
-   void pageDeleteError(@Cause Exception e);
+   void pageDeleteError(Exception e);
 
    @LogMessage(id = 222032, value = "page finalise error", level = LogMessage.Level.WARN)
-   void pageFinaliseError(@Cause Exception e);
+   void pageFinaliseError(Exception e);
 
    @LogMessage(id = 222033, value = "Page file {} had incomplete records at position {} at record number {}", level = LogMessage.Level.WARN)
    void pageSuspectFile(String fileName, int position, int msgNumber);
 
    @LogMessage(id = 222034, value = "Can not delete page transaction id={}", level = LogMessage.Level.WARN)
-   void pageTxDeleteError(long recordID, @Cause Exception e);
+   void pageTxDeleteError(long recordID, Exception e);
 
    @LogMessage(id = 222035, value = "Directory {} did not have an identification file {}", level = LogMessage.Level.WARN)
    void pageStoreFactoryNoIdFile(String s, String addressFile);
@@ -453,7 +452,7 @@ public interface ActiveMQServerLogger {
    void pageStoreTimeout(SimpleString address);
 
    @LogMessage(id = 222037, value = "IO Error, impossible to start paging", level = LogMessage.Level.WARN)
-   void pageStoreStartIOError(@Cause Exception e);
+   void pageStoreStartIOError(Exception e);
 
    @LogMessage(id = 222038, value = "Starting paging on address '{}'; {}", level = LogMessage.Level.INFO)
    void pageStoreStart(SimpleString storeName, String sizeInfo);
@@ -474,7 +473,7 @@ public interface ActiveMQServerLogger {
    void journalCannotFindQueueForMessage(Long queueID);
 
    @LogMessage(id = 222044, value = "It was not possible to delete message {}", level = LogMessage.Level.WARN)
-   void journalErrorDeletingMessage(Long messageID, @Cause Exception e);
+   void journalErrorDeletingMessage(Long messageID, Exception e);
 
    @LogMessage(id = 222045, value = "Message in prepared tx for queue {} which does not exist. This message will be ignored.", level = LogMessage.Level.WARN)
    void journalMessageInPreparedTX(Long queueID);
@@ -495,19 +494,19 @@ public interface ActiveMQServerLogger {
    void journalInvalidRecordTypeOnPreparedTX(Byte recordType);
 
    @LogMessage(id = 222051, value = "Journal Error", level = LogMessage.Level.WARN)
-   void journalError(@Cause Exception e);
+   void journalError(Exception e);
 
    @LogMessage(id = 222052, value = "error incrementing delay detection", level = LogMessage.Level.WARN)
-   void errorIncrementDelayDeletionCount(@Cause Exception e);
+   void errorIncrementDelayDeletionCount(Exception e);
 
    @LogMessage(id = 222053, value = "Error on copying large message {} for DLA or Expiry", level = LogMessage.Level.WARN)
-   void lareMessageErrorCopying(LargeServerMessage largeServerMessage, @Cause Exception e);
+   void lareMessageErrorCopying(LargeServerMessage largeServerMessage, Exception e);
 
    @LogMessage(id = 222054, value = "Error on executing IOCallback", level = LogMessage.Level.WARN)
-   void errorExecutingAIOCallback(@Cause Throwable t);
+   void errorExecutingAIOCallback(Throwable t);
 
    @LogMessage(id = 222055, value = "Error on deleting duplicate cache", level = LogMessage.Level.WARN)
-   void errorDeletingDuplicateCache(@Cause Exception e);
+   void errorDeletingDuplicateCache(Exception e);
 
    @LogMessage(id = 222056, value = "Did not route to any bindings for address {} and sendToDLAOnNoRoute is true but there is no DLA configured for the address, the message will be ignored.", level = LogMessage.Level.WARN)
    void noDLA(SimpleString address);
@@ -519,7 +518,7 @@ public interface ActiveMQServerLogger {
    void duplicateMessageDetected(org.apache.activemq.artemis.api.core.Message message);
 
    @LogMessage(id = 222060, value = "Error while confirming large message completion on rollback for recordID={}", level = LogMessage.Level.WARN)
-   void journalErrorConfirmingLargeMessage(Long messageID, @Cause Throwable e);
+   void journalErrorConfirmingLargeMessage(Long messageID, Throwable e);
 
    @LogMessage(id = 222061, value = "Client connection failed, clearing up resources for session {}", level = LogMessage.Level.WARN)
    void clientConnectionFailed(String name);
@@ -540,13 +539,13 @@ public interface ActiveMQServerLogger {
    void connectionFailureDetected(String message, ActiveMQExceptionType type);
 
    @LogMessage(id = 222069, value = "error cleaning up stomp connection", level = LogMessage.Level.WARN)
-   void errorCleaningStompConn(@Cause Exception e);
+   void errorCleaningStompConn(Exception e);
 
    @LogMessage(id = 222070, value = "Stomp Transactional acknowledgement is not supported", level = LogMessage.Level.WARN)
    void stompTXAckNorSupported();
 
    @LogMessage(id = 222071, value = "Interrupted while waiting for stomp heartbeat to die", level = LogMessage.Level.WARN)
-   void errorOnStompHeartBeat(@Cause InterruptedException e);
+   void errorOnStompHeartBeat(InterruptedException e);
 
    @LogMessage(id = 222072, value = "Timed out flushing channel on InVMConnection", level = LogMessage.Level.WARN)
    void timedOutFlushingInvmChannel();
@@ -564,19 +563,19 @@ public interface ActiveMQServerLogger {
    void nettyChannelStillBound(Channel channel, SocketAddress remoteAddress);
 
    @LogMessage(id = 222078, value = "Error instantiating remoting interceptor {}", level = LogMessage.Level.WARN)
-   void errorCreatingRemotingInterceptor(String interceptorClass, @Cause Exception e);
+   void errorCreatingRemotingInterceptor(String interceptorClass, Exception e);
 
    @LogMessage(id = 222079, value = "The following keys are invalid for configuring the acceptor: {} the acceptor will not be started.", level = LogMessage.Level.WARN)
    void invalidAcceptorKeys(String s);
 
    @LogMessage(id = 222080, value = "Error instantiating remoting acceptor {}", level = LogMessage.Level.WARN)
-   void errorCreatingAcceptor(String factoryClassName, @Cause Exception e);
+   void errorCreatingAcceptor(String factoryClassName, Exception e);
 
    @LogMessage(id = 222081, value = "Timed out waiting for remoting thread pool to terminate", level = LogMessage.Level.WARN)
    void timeoutRemotingThreadPool();
 
    @LogMessage(id = 222082, value = "error on connection failure check", level = LogMessage.Level.WARN)
-   void errorOnFailureCheck(@Cause Throwable e);
+   void errorOnFailureCheck(Throwable e);
 
    @LogMessage(id = 222083, value = "The following keys are invalid for configuring the connector service: {} the connector will not be started.", level = LogMessage.Level.WARN)
    void connectorKeysInvalid(String s);
@@ -588,16 +587,16 @@ public interface ActiveMQServerLogger {
    void invalidPacketForReplication(Packet packet);
 
    @LogMessage(id = 222086, value = "error handling packet {} for replication", level = LogMessage.Level.WARN)
-   void errorHandlingReplicationPacket(Packet packet, @Cause Exception e);
+   void errorHandlingReplicationPacket(Packet packet, Exception e);
 
    @LogMessage(id = 222087, value = "Replication Error while closing the page on backup", level = LogMessage.Level.WARN)
-   void errorClosingPageOnReplication(@Cause Exception e);
+   void errorClosingPageOnReplication(Exception e);
 
    @LogMessage(id = 222088, value = "Journal comparison mismatch:\n{}", level = LogMessage.Level.WARN)
    void journalcomparisonMismatch(String s);
 
    @LogMessage(id = 222089, value = "Replication Error deleting large message ID = {}", level = LogMessage.Level.WARN)
-   void errorDeletingLargeMessage(long messageId, @Cause Exception e);
+   void errorDeletingLargeMessage(long messageId, Exception e);
 
    @LogMessage(id = 222090, value = "Replication Large MessageID {}  is not available on backup server. Ignoring replication message", level = LogMessage.Level.WARN)
    void largeMessageNotAvailable(long messageId);
@@ -606,19 +605,19 @@ public interface ActiveMQServerLogger {
    void replicationStopOnBackupShutdown();
 
    @LogMessage(id = 222092, value = "Connection to the backup node failed, removing replication now", level = LogMessage.Level.WARN)
-   void replicationStopOnBackupFail(@Cause Exception e);
+   void replicationStopOnBackupFail(Exception e);
 
    @LogMessage(id = 222093, value = "Timed out waiting to stop Bridge", level = LogMessage.Level.WARN)
    void timedOutWaitingToStopBridge();
 
    @LogMessage(id = 222094, value = "Bridge unable to send message {}, will try again once bridge reconnects", level = LogMessage.Level.WARN)
-   void bridgeUnableToSendMessage(MessageReference ref, @Cause Exception e);
+   void bridgeUnableToSendMessage(MessageReference ref, Exception e);
 
    @LogMessage(id = 222095, value = "Connection failed with failedOver={}", level = LogMessage.Level.WARN)
    void bridgeConnectionFailed(Boolean failedOver);
 
    @LogMessage(id = 222096, value = "Error on querying binding on bridge {}. Retrying in 100 milliseconds", level = LogMessage.Level.WARN)
-   void errorQueryingBridge(String name, @Cause Throwable t);
+   void errorQueryingBridge(String name, Throwable t);
 
    @LogMessage(id = 222097, value = "Address {} does not have any bindings, retry #({})", level = LogMessage.Level.WARN)
    void errorQueryingBridge(String address, Integer retryCount);
@@ -627,7 +626,7 @@ public interface ActiveMQServerLogger {
    void errorStartingBridge(String name);
 
    @LogMessage(id = 222099, value = "Bridge {} is unable to connect to destination. It will be disabled.", level = LogMessage.Level.WARN)
-   void errorConnectingBridge(Bridge bridge, @Cause Exception e);
+   void errorConnectingBridge(Bridge bridge, Exception e);
 
    @LogMessage(id = 222100, value = "ServerLocator was shutdown, can not retry on opening connection for bridge", level = LogMessage.Level.WARN)
    void bridgeLocatorShutdown();
@@ -636,7 +635,7 @@ public interface ActiveMQServerLogger {
    void bridgeAbortStart(String name, Integer retryCount, Integer reconnectAttempts);
 
    @LogMessage(id = 222102, value = "Unexpected exception while trying to reconnect", level = LogMessage.Level.WARN)
-   void errorReConnecting(@Cause Exception e);
+   void errorReConnecting(Exception e);
 
    @LogMessage(id = 222103, value = "transaction with xid {} timed out", level = LogMessage.Level.WARN)
    void timedOutXID(Xid xid);
@@ -651,7 +650,7 @@ public interface ActiveMQServerLogger {
    void clientConnectionFailedClearingSession(String name);
 
    @LogMessage(id = 222108, value = "unable to send notification when broadcast group is stopped", level = LogMessage.Level.WARN)
-   void broadcastGroupClosed(@Cause Exception e);
+   void broadcastGroupClosed(Exception e);
 
    @LogMessage(id = 222109, value = "Timed out waiting for write lock on consumer {} from {}. Check the Thread dump", level = LogMessage.Level.WARN)
    void timeoutLockingConsumer(String consumer, String remoteAddress);
@@ -660,28 +659,28 @@ public interface ActiveMQServerLogger {
    void noQueueIdDefined(org.apache.activemq.artemis.api.core.Message message, org.apache.activemq.artemis.api.core.Message messageCopy, SimpleString idsHeaderName);
 
    @LogMessage(id = 222111, value = "exception while invoking {} on {}", level = LogMessage.Level.TRACE)
-   void managementOperationError(String op, String resourceName, @Cause Exception e);
+   void managementOperationError(String op, String resourceName, Exception e);
 
    @LogMessage(id = 222112, value = "exception while retrieving attribute {} on {}", level = LogMessage.Level.WARN)
-   void managementAttributeError(String att, String resourceName, @Cause Exception e);
+   void managementAttributeError(String att, String resourceName, Exception e);
 
    @LogMessage(id = 222113, value = "On ManagementService stop, there are {} unexpected registered MBeans: {}", level = LogMessage.Level.WARN)
    void managementStopError(Integer size, List<String> unexpectedResourceNames);
 
    @LogMessage(id = 222114, value = "Unable to delete group binding info {}", level = LogMessage.Level.WARN)
-   void unableToDeleteGroupBindings(SimpleString groupId, @Cause Exception e);
+   void unableToDeleteGroupBindings(SimpleString groupId, Exception e);
 
    @LogMessage(id = 222115, value = "Error closing serverLocator={}", level = LogMessage.Level.WARN)
-   void errorClosingServerLocator(ServerLocatorInternal clusterLocator, @Cause Exception e);
+   void errorClosingServerLocator(ServerLocatorInternal clusterLocator, Exception e);
 
    @LogMessage(id = 222116, value = "unable to start broadcast group {}", level = LogMessage.Level.WARN)
-   void unableToStartBroadcastGroup(String name, @Cause Exception e);
+   void unableToStartBroadcastGroup(String name, Exception e);
 
    @LogMessage(id = 222117, value = "unable to start cluster connection {}", level = LogMessage.Level.WARN)
-   void unableToStartClusterConnection(SimpleString name, @Cause Exception e);
+   void unableToStartClusterConnection(SimpleString name, Exception e);
 
    @LogMessage(id = 222118, value = "unable to start Bridge {}", level = LogMessage.Level.WARN)
-   void unableToStartBridge(SimpleString name, @Cause Exception e);
+   void unableToStartBridge(SimpleString name, Exception e);
 
    @LogMessage(id = 222119, value = "No connector with name {}. backup cannot be announced.", level = LogMessage.Level.WARN)
    void announceBackupNoConnector(String connectorName);
@@ -738,7 +737,7 @@ public interface ActiveMQServerLogger {
    void ioErrorRedistributing(Integer errorCode, String errorMessage);
 
    @LogMessage(id = 222137, value = "Unable to announce backup, retrying", level = LogMessage.Level.WARN)
-   void errorAnnouncingBackup(@Cause Throwable e);
+   void errorAnnouncingBackup(Throwable e);
 
    @LogMessage(id = 222138, value = "Local Member is not set at on ClusterConnection {}", level = LogMessage.Level.WARN)
    void noLocalMemborOnClusterConnection(ClusterConnectionImpl clusterConnection);
@@ -747,10 +746,10 @@ public interface ActiveMQServerLogger {
    void remoteQueueAlreadyBoundOnClusterConnection(Object messageFlowRecord, SimpleString clusterName);
 
    @LogMessage(id = 222141, value = "Node Manager can not open file {}", level = LogMessage.Level.WARN)
-   void nodeManagerCantOpenFile(File file, @Cause Exception e);
+   void nodeManagerCantOpenFile(File file, Exception e);
 
    @LogMessage(id = 222142, value = "Error on resetting large message deliver - {}", level = LogMessage.Level.WARN)
-   void errorResttingLargeMessage(Object deliverer, @Cause Throwable e);
+   void errorResttingLargeMessage(Object deliverer, Throwable e);
 
    @LogMessage(id = 222143, value = "Timed out waiting for executor to complete", level = LogMessage.Level.WARN)
    void errorTransferringConsumer();
@@ -759,7 +758,7 @@ public interface ActiveMQServerLogger {
    void errorFlushingExecutorsOnQueue();
 
    @LogMessage(id = 222145, value = "Error expiring reference {} on queue", level = LogMessage.Level.WARN)
-   void errorExpiringReferencesOnQueue(MessageReference ref, @Cause Exception e);
+   void errorExpiringReferencesOnQueue(MessageReference ref, Exception e);
 
    @LogMessage(id = 222146, value = "Message has expired. No bindings for Expiry Address {} so dropping it", level = LogMessage.Level.WARN)
    void errorExpiringReferencesNoBindings(SimpleString expiryAddress);
@@ -777,16 +776,16 @@ public interface ActiveMQServerLogger {
    void messageExceededMaxDeliveryNoDLA(MessageReference ref, SimpleString name);
 
    @LogMessage(id = 222151, value = "removing consumer which did not handle a message, consumer={}, message={}", level = LogMessage.Level.WARN)
-   void removingBadConsumer(Consumer consumer, Object reference, @Cause Throwable e);
+   void removingBadConsumer(Consumer consumer, Object reference, Throwable e);
 
    @LogMessage(id = 222152, value = "Unable to decrement reference counting on queue", level = LogMessage.Level.WARN)
-   void errorDecrementingRefCount(@Cause Throwable e);
+   void errorDecrementingRefCount(Throwable e);
 
    @LogMessage(id = 222153, value = "Cannot locate record for message id = {} on Journal", level = LogMessage.Level.WARN)
-   void cannotFindMessageOnJournal(Long messageID, @Cause Throwable e);
+   void cannotFindMessageOnJournal(Long messageID, Throwable e);
 
    @LogMessage(id = 222154, value = "Error checking DLQ", level = LogMessage.Level.WARN)
-   void errorCheckingDLQ(@Cause Throwable e);
+   void errorCheckingDLQ(Throwable e);
 
    @LogMessage(id = 222155, value = "Failed to register as backup. Stopping the server.", level = LogMessage.Level.WARN)
    void errorRegisteringBackup();
@@ -795,16 +794,16 @@ public interface ActiveMQServerLogger {
    void memoryError(Integer memoryWarningThreshold, String info);
 
    @LogMessage(id = 222157, value = "Error completing callback on replication manager", level = LogMessage.Level.WARN)
-   void errorCompletingCallbackOnReplicationManager(@Cause Throwable e);
+   void errorCompletingCallbackOnReplicationManager(Throwable e);
 
    @LogMessage(id = 222158, value = "{} activation thread did not finish.", level = LogMessage.Level.WARN)
    void activationDidntFinish(ActiveMQServer server);
 
    @LogMessage(id = 222159, value = "unable to send notification when broadcast group is stopped", level = LogMessage.Level.WARN)
-   void broadcastBridgeStoppedError(@Cause Exception e);
+   void broadcastBridgeStoppedError(Exception e);
 
    @LogMessage(id = 222160, value = "unable to send notification when broadcast group is stopped", level = LogMessage.Level.WARN)
-   void notificationBridgeStoppedError(@Cause Exception e);
+   void notificationBridgeStoppedError(Exception e);
 
    @LogMessage(id = 222161, value = "Group Handler timed-out waiting for sendCondition", level = LogMessage.Level.WARN)
    void groupHandlerSendTimeout();
@@ -859,10 +858,10 @@ public interface ActiveMQServerLogger {
    void rolePermissionConfigurationError(String permission);
 
    @LogMessage(id = 222178, value = "Error during recovery of page counters", level = LogMessage.Level.WARN)
-   void errorRecoveringPageCounter(@Cause Throwable error);
+   void errorRecoveringPageCounter(Throwable error);
 
    @LogMessage(id = 222181, value = "Unable to scaleDown messages", level = LogMessage.Level.WARN)
-   void failedToScaleDown(@Cause Throwable e);
+   void failedToScaleDown(Throwable e);
 
    @LogMessage(id = 222182, value = "Missing cluster-configuration for scale-down-clustername {}", level = LogMessage.Level.WARN)
    void missingClusterConfigForScaleDown(String scaleDownCluster);
@@ -880,13 +879,13 @@ public interface ActiveMQServerLogger {
    void clusterControlAuthfailure(String causeMessage);
 
    @LogMessage(id = 222187, value = "Failed to activate replicated backup", level = LogMessage.Level.WARN)
-   void activateReplicatedBackupFailed(@Cause Throwable e);
+   void activateReplicatedBackupFailed(Throwable e);
 
    @LogMessage(id = 222188, value = "Unable to find target queue for node {}", level = LogMessage.Level.WARN)
    void unableToFindTargetQueue(String targetNodeID);
 
    @LogMessage(id = 222189, value = "Failed to activate shared store slave", level = LogMessage.Level.WARN)
-   void activateSharedStoreSlaveFailed(@Cause Throwable e);
+   void activateSharedStoreSlaveFailed(Throwable e);
 
    @LogMessage(id = 222191, value = "Could not find any configured role for user {}.", level = LogMessage.Level.WARN)
    void cannotFindRoleForUser(String user);
@@ -973,163 +972,163 @@ public interface ActiveMQServerLogger {
    void connectorRefNotFound(String connectorRef, String clusterConnection);
 
    @LogMessage(id = 222218, value = "Server disconnecting: {}", level = LogMessage.Level.WARN)
-   void disconnectCritical(String reason, @Cause Exception e);
+   void disconnectCritical(String reason, Exception e);
 
    @LogMessage(id = 222219, value = "File {} does not exist", level = LogMessage.Level.WARN)
    void fileDoesNotExist(String path);
 
    @LogMessage(id = 222220, value = "   Error while cleaning paging on queue {}", level = LogMessage.Level.WARN)
-   void errorCleaningPagingOnQueue(String queue, @Cause Exception e);
+   void errorCleaningPagingOnQueue(String queue, Exception e);
 
    @LogMessage(id = 222221, value = "Error while cleaning page, during the commit", level = LogMessage.Level.WARN)
-   void errorCleaningPagingDuringCommit(@Cause Exception e);
+   void errorCleaningPagingDuringCommit(Exception e);
 
    @LogMessage(id = 222222, value = "Error while deleting page-complete-record", level = LogMessage.Level.WARN)
-   void errorDeletingPageCompleteRecord(@Cause Exception e);
+   void errorDeletingPageCompleteRecord(Exception e);
 
    @LogMessage(id = 222223, value = "Failed to calculate message memory estimate", level = LogMessage.Level.WARN)
-   void errorCalculateMessageMemoryEstimate(@Cause Throwable e);
+   void errorCalculateMessageMemoryEstimate(Throwable e);
 
    @LogMessage(id = 222224, value = "Failed to calculate scheduled delivery time", level = LogMessage.Level.WARN)
-   void errorCalculateScheduledDeliveryTime(@Cause Throwable e);
+   void errorCalculateScheduledDeliveryTime(Throwable e);
 
    @LogMessage(id = 222225, value = "Sending unexpected exception to the client", level = LogMessage.Level.WARN)
-   void sendingUnexpectedExceptionToClient(@Cause Throwable e);
+   void sendingUnexpectedExceptionToClient(Throwable e);
 
    @LogMessage(id = 222226, value = "Connection configuration is null for connectorName {}", level = LogMessage.Level.WARN)
    void connectionConfigurationIsNull(String connectorName);
 
    @LogMessage(id = 222227, value = "Failed to process an event", level = LogMessage.Level.WARN)
-   void failedToProcessEvent(@Cause NamingException e);
+   void failedToProcessEvent(NamingException e);
 
    @LogMessage(id = 222228, value = "Missing replication token on queue", level = LogMessage.Level.WARN)
    void missingReplicationTokenOnQueue();
 
    @LogMessage(id = 222229, value = "Failed to perform rollback", level = LogMessage.Level.WARN)
-   void failedToPerformRollback(@Cause IllegalStateException e);
+   void failedToPerformRollback(IllegalStateException e);
 
    @LogMessage(id = 222230, value = "Failed to send notification", level = LogMessage.Level.WARN)
-   void failedToSendNotification(@Cause Exception e);
+   void failedToSendNotification(Exception e);
 
    @LogMessage(id = 222231, value = "Failed to flush outstanding data from the connection", level = LogMessage.Level.WARN)
-   void failedToFlushOutstandingDataFromTheConnection(@Cause Throwable e);
+   void failedToFlushOutstandingDataFromTheConnection(Throwable e);
 
    @LogMessage(id = 222232, value = "Unable to acquire lock", level = LogMessage.Level.WARN)
-   void unableToAcquireLock(@Cause Exception e);
+   void unableToAcquireLock(Exception e);
 
    @LogMessage(id = 222233, value = "Unable to destroy connection with session metadata", level = LogMessage.Level.WARN)
-   void unableDestroyConnectionWithSessionMetadata(@Cause Throwable e);
+   void unableDestroyConnectionWithSessionMetadata(Throwable e);
 
    @LogMessage(id = 222234, value = "Unable to invoke a callback", level = LogMessage.Level.WARN)
-   void unableToInvokeCallback(@Cause Throwable e);
+   void unableToInvokeCallback(Throwable e);
 
    @LogMessage(id = 222235, value = "Unable to inject a monitor", level = LogMessage.Level.WARN)
-   void unableToInjectMonitor(@Cause Throwable e);
+   void unableToInjectMonitor(Throwable e);
 
    @LogMessage(id = 222236, value = "Unable to flush deliveries", level = LogMessage.Level.WARN)
-   void unableToFlushDeliveries(@Cause Exception e);
+   void unableToFlushDeliveries(Exception e);
 
    @LogMessage(id = 222237, value = "Unable to stop redistributor", level = LogMessage.Level.WARN)
-   void unableToCancelRedistributor(@Cause Exception e);
+   void unableToCancelRedistributor(Exception e);
 
    @LogMessage(id = 222238, value = "Unable to commit transaction", level = LogMessage.Level.WARN)
-   void unableToCommitTransaction(@Cause Exception e);
+   void unableToCommitTransaction(Exception e);
 
    @LogMessage(id = 222239, value = "Unable to delete Queue status", level = LogMessage.Level.WARN)
-   void unableToDeleteQueueStatus(@Cause Exception e);
+   void unableToDeleteQueueStatus(Exception e);
 
    @LogMessage(id = 222240, value = "Unable to pause a Queue", level = LogMessage.Level.WARN)
-   void unableToPauseQueue(@Cause Exception e);
+   void unableToPauseQueue(Exception e);
 
    @LogMessage(id = 222241, value = "Unable to resume a Queue", level = LogMessage.Level.WARN)
-   void unableToResumeQueue(@Cause Exception e);
+   void unableToResumeQueue(Exception e);
 
    @LogMessage(id = 222242, value = "Unable to obtain message priority, using default ", level = LogMessage.Level.WARN)
-   void unableToGetMessagePriority(@Cause Throwable e);
+   void unableToGetMessagePriority(Throwable e);
 
    @LogMessage(id = 222243, value = "Unable to extract GroupID from message", level = LogMessage.Level.WARN)
-   void unableToExtractGroupID(@Cause Throwable e);
+   void unableToExtractGroupID(Throwable e);
 
    @LogMessage(id = 222244, value = "Unable to check if message expired", level = LogMessage.Level.WARN)
-   void unableToCheckIfMessageExpired(@Cause Throwable e);
+   void unableToCheckIfMessageExpired(Throwable e);
 
    @LogMessage(id = 222245, value = "Unable to perform post acknowledge", level = LogMessage.Level.WARN)
-   void unableToPerformPostAcknowledge(@Cause Throwable e);
+   void unableToPerformPostAcknowledge(Throwable e);
 
    @LogMessage(id = 222246, value = "Unable to rollback on close", level = LogMessage.Level.WARN)
-   void unableToRollbackOnClose(@Cause Exception e);
+   void unableToRollbackOnClose(Exception e);
 
    @LogMessage(id = 222247, value = "Unable to close consumer", level = LogMessage.Level.WARN)
-   void unableToCloseConsumer(@Cause Throwable e);
+   void unableToCloseConsumer(Throwable e);
 
    @LogMessage(id = 222248, value = "Unable to remove consumer", level = LogMessage.Level.WARN)
-   void unableToRemoveConsumer(@Cause Throwable e);
+   void unableToRemoveConsumer(Throwable e);
 
    @LogMessage(id = 222249, value = "Unable to rollback on TX timed out", level = LogMessage.Level.WARN)
-   void unableToRollbackOnTxTimedOut(@Cause Exception e);
+   void unableToRollbackOnTxTimedOut(Exception e);
 
    @LogMessage(id = 222250, value = "Unable to delete heuristic completion from storage manager", level = LogMessage.Level.WARN)
-   void unableToDeleteHeuristicCompletion(@Cause Exception e);
+   void unableToDeleteHeuristicCompletion(Exception e);
 
    @LogMessage(id = 222251, value = "Unable to start replication", level = LogMessage.Level.WARN)
-   void unableToStartReplication(@Cause Exception e);
+   void unableToStartReplication(Exception e);
 
    @LogMessage(id = 222252, value = "Unable to calculate file size", level = LogMessage.Level.WARN)
-   void unableToCalculateFileSize(@Cause Exception e);
+   void unableToCalculateFileSize(Exception e);
 
    @LogMessage(id = 222253, value = "Error while syncing data on largeMessageInSync:: {}", level = LogMessage.Level.WARN)
-   void errorWhileSyncingData(String target, @Cause Throwable e);
+   void errorWhileSyncingData(String target, Throwable e);
 
    @LogMessage(id = 222254, value = "Invalid record type {}", level = LogMessage.Level.WARN)
-   void invalidRecordType(byte type, @Cause Throwable e);
+   void invalidRecordType(byte type, Throwable e);
 
    @LogMessage(id = 222255, value = "Unable to calculate file store usage", level = LogMessage.Level.WARN)
-   void unableToCalculateFileStoreUsage(@Cause Exception e);
+   void unableToCalculateFileStoreUsage(Exception e);
 
    @LogMessage(id = 222256, value = "Failed to unregister acceptors", level = LogMessage.Level.WARN)
-   void failedToUnregisterAcceptors(@Cause Exception e);
+   void failedToUnregisterAcceptors(Exception e);
 
    @LogMessage(id = 222257, value = "Failed to decrement message reference count", level = LogMessage.Level.WARN)
-   void failedToDecrementMessageReferenceCount(@Cause Exception e);
+   void failedToDecrementMessageReferenceCount(Exception e);
 
    @LogMessage(id = 222258, value = "Error on deleting queue {}", level = LogMessage.Level.WARN)
-   void errorOnDeletingQueue(String queueName, @Cause Exception e);
+   void errorOnDeletingQueue(String queueName, Exception e);
 
    @LogMessage(id = 222259, value = "Failed to flush the executor", level = LogMessage.Level.WARN)
-   void failedToFlushExecutor(@Cause InterruptedException e);
+   void failedToFlushExecutor(InterruptedException e);
 
    @LogMessage(id = 222260, value = "Failed to perform rollback", level = LogMessage.Level.WARN)
-   void failedToRollback(@Cause Exception e);
+   void failedToRollback(Exception e);
 
    @LogMessage(id = 222261, value = "Failed to activate a backup", level = LogMessage.Level.WARN)
-   void failedToActivateBackup(@Cause Exception e);
+   void failedToActivateBackup(Exception e);
 
    @LogMessage(id = 222262, value = "Failed to stop cluster manager", level = LogMessage.Level.WARN)
-   void failedToStopClusterManager(@Cause Exception e);
+   void failedToStopClusterManager(Exception e);
 
    @LogMessage(id = 222263, value = "Failed to stop cluster connection", level = LogMessage.Level.WARN)
-   void failedToStopClusterConnection(@Cause Exception e);
+   void failedToStopClusterConnection(Exception e);
 
    @LogMessage(id = 222264, value = "Failed to process message reference after rollback", level = LogMessage.Level.WARN)
-   void failedToProcessMessageReferenceAfterRollback(@Cause Exception e);
+   void failedToProcessMessageReferenceAfterRollback(Exception e);
 
    @LogMessage(id = 222265, value = "Failed to finish delivery, unable to lock delivery", level = LogMessage.Level.WARN)
-   void failedToFinishDelivery(@Cause Exception e);
+   void failedToFinishDelivery(Exception e);
 
    @LogMessage(id = 222266, value = "Failed to send request to the node", level = LogMessage.Level.WARN)
-   void failedToSendRequestToNode(@Cause Exception e);
+   void failedToSendRequestToNode(Exception e);
 
    @LogMessage(id = 222267, value = "Failed to disconnect bindings", level = LogMessage.Level.WARN)
-   void failedToDisconnectBindings(@Cause Exception e);
+   void failedToDisconnectBindings(Exception e);
 
    @LogMessage(id = 222268, value = "Failed to remove a record", level = LogMessage.Level.WARN)
-   void failedToRemoveRecord(@Cause Exception e);
+   void failedToRemoveRecord(Exception e);
 
    @LogMessage(id = 222269, value = "Please use a fixed value for \"journal-pool-files\". Default changed per https://issues.apache.org/jira/browse/ARTEMIS-1628", level = LogMessage.Level.WARN)
    void useFixedValueOnJournalPoolFiles();
 
    @LogMessage(id = 222270, value = "Unable to create management notification address: {}", level = LogMessage.Level.WARN)
-   void unableToCreateManagementNotificationAddress(SimpleString addressName, @Cause Exception e);
+   void unableToCreateManagementNotificationAddress(SimpleString addressName, Exception e);
 
    @LogMessage(id = 22272, value = "Message ack in prepared tx for queue {} which does not exist. This ack will be ignored.", level = LogMessage.Level.WARN)
    void journalMessageAckMissingQueueInPreparedTX(Long queueID);
@@ -1144,13 +1143,13 @@ public interface ActiveMQServerLogger {
    void problemDeployingQueue(String queueName, String message);
 
    @LogMessage(id = 222276, value = "Failed to process changes to the logging configuration file: {}", level = LogMessage.Level.WARN)
-   void loggingReloadFailed(String configFile, @Cause Exception e);
+   void loggingReloadFailed(String configFile, Exception e);
 
    @LogMessage(id = 222277, value = "Problem initializing automatic logging configuration reload for {}", level = LogMessage.Level.WARN)
-   void problemAddingConfigReloadCallback(String propertyName, @Cause Exception e);
+   void problemAddingConfigReloadCallback(String propertyName, Exception e);
 
    @LogMessage(id = 222278, value = "Unable to extract GroupSequence from message", level = LogMessage.Level.WARN)
-   void unableToExtractGroupSequence(@Cause Throwable e);
+   void unableToExtractGroupSequence(Throwable e);
 
    @LogMessage(id = 222279, value = "Federation upstream {} policy ref {} could not be resolved in federation configuration", level = LogMessage.Level.WARN)
    void federationCantFindPolicyRef(String upstreamName, String policyRef);
@@ -1174,10 +1173,10 @@ public interface ActiveMQServerLogger {
    void emptyAddressFile(String addressFile, String directory);
 
    @LogMessage(id = 222286, value = "Error executing {} federation plugin method.", level = LogMessage.Level.WARN)
-   void federationPluginExecutionError(String pluginMethod, @Cause Throwable e);
+   void federationPluginExecutionError(String pluginMethod, Throwable e);
 
    @LogMessage(id = 222287, value = "Error looking up bindings for address {}.", level = LogMessage.Level.WARN)
-   void federationBindingsLookupError(SimpleString address, @Cause Throwable e);
+   void federationBindingsLookupError(SimpleString address, Throwable e);
 
    @LogMessage(id = 222288, value = "Page {}, message {} could not be found on offset {}, with starting message {}. This represents a logic error or inconsistency on the data, and the system will try once again from the beggining of the page file.", level = LogMessage.Level.WARN)
    void pageLookupError(long pageNr, int messageNr, int offset, int startNr);
@@ -1204,13 +1203,13 @@ public interface ActiveMQServerLogger {
 
 
    @LogMessage(id = 222296, value = "Unable to deploy Hawtio MBeam, console client side RBAC not available", level = LogMessage.Level.WARN)
-   void unableToDeployHawtioMBean(@Cause Exception e);
+   void unableToDeployHawtioMBean(Exception e);
 
    @LogMessage(id = 222297, value = "Unable to start Management Context, RBAC not available", level = LogMessage.Level.WARN)
-   void unableStartManagementContext(@Cause Exception e);
+   void unableStartManagementContext(Exception e);
 
    @LogMessage(id = 222298, value = "Failed to create bootstrap user \"{}\". User management may not function.", level = LogMessage.Level.WARN)
-   void failedToCreateBootstrapCredentials(String user, @Cause Exception e);
+   void failedToCreateBootstrapCredentials(String user, Exception e);
 
    @LogMessage(id = 222299, value = "No bootstrap credentials found. User management may not function.", level = LogMessage.Level.WARN)
    void noBootstrapCredentialsFound();
@@ -1225,16 +1224,16 @@ public interface ActiveMQServerLogger {
    void failedToDealWithObjectProperty(SimpleString property, String exceptionMessage);
 
    @LogMessage(id = 222303, value = "Redistribution by {} of messageID = {} failed", level = LogMessage.Level.WARN)
-   void errorRedistributing(String queueName, long m, @Cause Throwable t);
+   void errorRedistributing(String queueName, long m, Throwable t);
 
    @LogMessage(id = 222304, value = "Unable to load message from journal", level = LogMessage.Level.WARN)
-   void unableToLoadMessageFromJournal(@Cause Throwable t);
+   void unableToLoadMessageFromJournal(Throwable t);
 
    @LogMessage(id = 222305, value = "Error federating message {}.", level = LogMessage.Level.WARN)
-   void federationDispatchError(String message, @Cause Throwable e);
+   void federationDispatchError(String message, Throwable e);
 
    @LogMessage(id = 222306, value = "Failed to load prepared TX and it will be rolled back: {}", level = LogMessage.Level.WARN)
-   void failedToLoadPreparedTX(String message, @Cause Throwable e);
+   void failedToLoadPreparedTX(String message, Throwable e);
 
    @LogMessage(id = 222307, value = "The queues element is deprecated and replaced by the addresses element", level = LogMessage.Level.WARN)
    void queuesElementDeprecated();
@@ -1245,19 +1244,19 @@ public interface ActiveMQServerLogger {
 
 
    @LogMessage(id = 224000, value = "Failure in initialisation", level = LogMessage.Level.ERROR)
-   void initializationError(@Cause Throwable e);
+   void initializationError(Throwable e);
 
    @LogMessage(id = 224001, value = "Error deploying URI {}", level = LogMessage.Level.ERROR)
-   void errorDeployingURI(URI uri, @Cause Throwable e);
+   void errorDeployingURI(URI uri, Throwable e);
 
    @LogMessage(id = 224002, value = "Error deploying URI", level = LogMessage.Level.ERROR)
-   void errorDeployingURI(@Cause Throwable e);
+   void errorDeployingURI(Throwable e);
 
    @LogMessage(id = 224003, value = "Error undeploying URI {}", level = LogMessage.Level.ERROR)
-   void errorUnDeployingURI(URI a, @Cause Throwable e);
+   void errorUnDeployingURI(URI a, Throwable e);
 
    @LogMessage(id = 224005, value = "Unable to deploy node {}", level = LogMessage.Level.ERROR)
-   void unableToDeployNode(Node node, @Cause Exception e);
+   void unableToDeployNode(Node node, Exception e);
 
    @LogMessage(id = 224006, value = "Invalid filter: {}", level = LogMessage.Level.ERROR)
    void invalidFilter(SimpleString filter);
@@ -1266,7 +1265,7 @@ public interface ActiveMQServerLogger {
    void pageSubscriptionError(IOCallback IOCallback, String error);
 
    @LogMessage(id = 224008, value = "Failed to store id", level = LogMessage.Level.ERROR)
-   void batchingIdError(@Cause Exception e);
+   void batchingIdError(Exception e);
 
    @LogMessage(id = 224009, value = "Cannot find message {}", level = LogMessage.Level.ERROR)
    void cannotFindMessage(Long id);
@@ -1278,40 +1277,40 @@ public interface ActiveMQServerLogger {
    void journalCannotFindQueueScheduled(Long queue, Long id);
 
    @LogMessage(id = 224012, value = "error releasing resources", level = LogMessage.Level.ERROR)
-   void largeMessageErrorReleasingResources(@Cause Exception e);
+   void largeMessageErrorReleasingResources(Exception e);
 
    @LogMessage(id = 224014, value = "Failed to close session", level = LogMessage.Level.ERROR)
-   void errorClosingSession(@Cause Exception e);
+   void errorClosingSession(Exception e);
 
    @LogMessage(id = 224015, value = "Caught XA exception", level = LogMessage.Level.ERROR)
-   void caughtXaException(@Cause Exception e);
+   void caughtXaException(Exception e);
 
    @LogMessage(id = 224016, value = "Caught exception", level = LogMessage.Level.ERROR)
-   void caughtException(@Cause Throwable e);
+   void caughtException(Throwable e);
 
    @LogMessage(id = 224017, value = "Invalid packet {}", level = LogMessage.Level.ERROR)
    void invalidPacket(Packet packet);
 
    @LogMessage(id = 224018, value = "Failed to create session", level = LogMessage.Level.ERROR)
-   void failedToCreateSession(@Cause Exception e);
+   void failedToCreateSession(Exception e);
 
    @LogMessage(id = 224019, value = "Failed to reattach session", level = LogMessage.Level.ERROR)
-   void failedToReattachSession(@Cause Exception e);
+   void failedToReattachSession(Exception e);
 
    @LogMessage(id = 224020, value = "Failed to handle create queue", level = LogMessage.Level.ERROR)
-   void failedToHandleCreateQueue(@Cause Exception e);
+   void failedToHandleCreateQueue(Exception e);
 
    @LogMessage(id = 224021, value = "Failed to decode packet", level = LogMessage.Level.ERROR)
-   void errorDecodingPacket(@Cause Exception e);
+   void errorDecodingPacket(Exception e);
 
    @LogMessage(id = 224022, value = "Failed to execute failure listener", level = LogMessage.Level.ERROR)
-   void errorCallingFailureListener(@Cause Throwable e);
+   void errorCallingFailureListener(Throwable e);
 
    @LogMessage(id = 224024, value = "Stomp Error, tx already exist! {}", level = LogMessage.Level.ERROR)
    void stompErrorTXExists(String txID);
 
    @LogMessage(id = 224027, value = "Failed to write to handler on invm connector {}", level = LogMessage.Level.ERROR)
-   void errorWritingToInvmConnector(Runnable runnable, @Cause Exception e);
+   void errorWritingToInvmConnector(Runnable runnable, Exception e);
 
    @LogMessage(id = 224028, value = "Failed to stop acceptor {}", level = LogMessage.Level.ERROR)
    void errorStoppingAcceptor(String name);
@@ -1320,58 +1319,58 @@ public interface ActiveMQServerLogger {
    void largeMessageIncompatible();
 
    @LogMessage(id = 224030, value = "Could not cancel reference {}", level = LogMessage.Level.ERROR)
-   void errorCancellingRefOnBridge(MessageReference ref2, @Cause Exception e);
+   void errorCancellingRefOnBridge(MessageReference ref2, Exception e);
 
    @LogMessage(id = 224032, value = "Failed to pause bridge", level = LogMessage.Level.ERROR)
-   void errorPausingBridge(@Cause Exception e);
+   void errorPausingBridge(Exception e);
 
    @LogMessage(id = 224033, value = "Failed to broadcast connector configs", level = LogMessage.Level.ERROR)
-   void errorBroadcastingConnectorConfigs(@Cause Exception e);
+   void errorBroadcastingConnectorConfigs(Exception e);
 
    @LogMessage(id = 224034, value = "Failed to close consumer", level = LogMessage.Level.ERROR)
-   void errorClosingConsumer(@Cause Exception e);
+   void errorClosingConsumer(Exception e);
 
    @LogMessage(id = 224035, value = "Failed to close cluster connection flow record", level = LogMessage.Level.ERROR)
-   void errorClosingFlowRecord(@Cause Exception e);
+   void errorClosingFlowRecord(Exception e);
 
    @LogMessage(id = 224036, value = "Failed to update cluster connection topology", level = LogMessage.Level.ERROR)
-   void errorUpdatingTopology(@Cause Exception e);
+   void errorUpdatingTopology(Exception e);
 
    @LogMessage(id = 224037, value = "cluster connection Failed to handle message", level = LogMessage.Level.ERROR)
-   void errorHandlingMessage(@Cause Exception e);
+   void errorHandlingMessage(Exception e);
 
    @LogMessage(id = 224038, value = "Failed to ack old reference", level = LogMessage.Level.ERROR)
-   void errorAckingOldReference(@Cause Exception e);
+   void errorAckingOldReference(Exception e);
 
    @LogMessage(id = 224039, value = "Failed to expire message reference", level = LogMessage.Level.ERROR)
-   void errorExpiringRef(@Cause Exception e);
+   void errorExpiringRef(Exception e);
 
    @LogMessage(id = 224040, value = "Failed to remove consumer", level = LogMessage.Level.ERROR)
-   void errorRemovingConsumer(@Cause Exception e);
+   void errorRemovingConsumer(Exception e);
 
    @LogMessage(id = 224041, value = "Failed to deliver", level = LogMessage.Level.ERROR)
-   void errorDelivering(@Cause Exception e);
+   void errorDelivering(Exception e);
 
    @LogMessage(id = 224042, value = "Error while restarting the backup server: {}", level = LogMessage.Level.ERROR)
-   void errorRestartingBackupServer(ActiveMQServer backup, @Cause Exception e);
+   void errorRestartingBackupServer(ActiveMQServer backup, Exception e);
 
    @LogMessage(id = 224043, value = "Failed to send forced delivery message", level = LogMessage.Level.ERROR)
-   void errorSendingForcedDelivery(@Cause Exception e);
+   void errorSendingForcedDelivery(Exception e);
 
    @LogMessage(id = 224044, value = "error acknowledging message", level = LogMessage.Level.ERROR)
-   void errorAckingMessage(@Cause Exception e);
+   void errorAckingMessage(Exception e);
 
    @LogMessage(id = 224045, value = "Failed to run large message deliverer", level = LogMessage.Level.ERROR)
-   void errorRunningLargeMessageDeliverer(@Cause Exception e);
+   void errorRunningLargeMessageDeliverer(Exception e);
 
    @LogMessage(id = 224046, value = "Exception while browser handled from {}", level = LogMessage.Level.ERROR)
-   void errorBrowserHandlingMessage(MessageReference current, @Cause Exception e);
+   void errorBrowserHandlingMessage(MessageReference current, Exception e);
 
    @LogMessage(id = 224047, value = "Failed to delete large message file", level = LogMessage.Level.ERROR)
-   void errorDeletingLargeMessageFile(@Cause Throwable e);
+   void errorDeletingLargeMessageFile(Throwable e);
 
    @LogMessage(id = 224048, value = "Failed to remove temporary queue {}", level = LogMessage.Level.ERROR)
-   void errorRemovingTempQueue(SimpleString bindingName, @Cause Exception e);
+   void errorRemovingTempQueue(SimpleString bindingName, Exception e);
 
    @LogMessage(id = 224049, value = "Cannot find consumer with id {}", level = LogMessage.Level.ERROR)
    void cannotFindConsumer(long consumerID);
@@ -1380,19 +1379,19 @@ public interface ActiveMQServerLogger {
    void errorClosingConnection(ServerSessionImpl serverSession);
 
    @LogMessage(id = 224051, value = "Failed to call notification listener", level = LogMessage.Level.ERROR)
-   void errorCallingNotifListener(@Cause Exception e);
+   void errorCallingNotifListener(Exception e);
 
    @LogMessage(id = 224052, value = "Unable to call Hierarchical Repository Change Listener", level = LogMessage.Level.ERROR)
-   void errorCallingRepoListener(@Cause Throwable e);
+   void errorCallingRepoListener(Throwable e);
 
    @LogMessage(id = 224053, value = "failed to timeout transaction, xid:{}", level = LogMessage.Level.ERROR)
-   void errorTimingOutTX(Xid xid, @Cause Exception e);
+   void errorTimingOutTX(Xid xid, Exception e);
 
    @LogMessage(id = 224054, value = "exception while stopping the replication manager", level = LogMessage.Level.ERROR)
-   void errorStoppingReplicationManager(@Cause Throwable t);
+   void errorStoppingReplicationManager(Throwable t);
 
    @LogMessage(id = 224055, value = "Bridge Failed to ack", level = LogMessage.Level.ERROR)
-   void bridgeFailedToAck(@Cause Throwable t);
+   void bridgeFailedToAck(Throwable t);
 
    @LogMessage(id = 224056, value = "Live server will not fail-back automatically", level = LogMessage.Level.ERROR)
    void autoFailBackDenied();
@@ -1414,29 +1413,29 @@ public interface ActiveMQServerLogger {
    void incompatibleWithHAPolicy(String parameter);
 
    @LogMessage(id = 224062, value = "Failed to send SLOW_CONSUMER notification: {}", level = LogMessage.Level.ERROR)
-   void failedToSendSlowConsumerNotification(Notification notification, @Cause Exception e);
+   void failedToSendSlowConsumerNotification(Notification notification, Exception e);
 
    @LogMessage(id = 224063, value = "Failed to close consumer connections for address {}", level = LogMessage.Level.ERROR)
-   void failedToCloseConsumerConnectionsForAddress(String address, @Cause Exception e);
+   void failedToCloseConsumerConnectionsForAddress(String address, Exception e);
 
    @Deprecated(since = "1.0.0")
    @LogMessage(id = 224064, value = "Setting <{}> is invalid with this HA Policy Configuration. Please use <ha-policy> exclusively or remove. Ignoring value.", level = LogMessage.Level.ERROR)
    void incompatibleWithHAPolicyChosen(String parameter);
 
    @LogMessage(id = 224065, value = "Failed to remove auto-created {} {}", level = LogMessage.Level.ERROR)
-   void errorRemovingAutoCreatedDestination(String destinationType, SimpleString bindingName, @Cause Exception e);
+   void errorRemovingAutoCreatedDestination(String destinationType, SimpleString bindingName, Exception e);
 
    @LogMessage(id = 224066, value = "Error opening context for LDAP", level = LogMessage.Level.ERROR)
-   void errorOpeningContextForLDAP(@Cause Exception e);
+   void errorOpeningContextForLDAP(Exception e);
 
    @LogMessage(id = 224067, value = "Error populating security roles from LDAP", level = LogMessage.Level.ERROR)
-   void errorPopulatingSecurityRolesFromLDAP(@Cause Exception e);
+   void errorPopulatingSecurityRolesFromLDAP(Exception e);
 
    @LogMessage(id = 224068, value = "Unable to stop component: {}", level = LogMessage.Level.ERROR)
-   void errorStoppingComponent(String componentClassName, @Cause Throwable t);
+   void errorStoppingComponent(String componentClassName, Throwable t);
 
    @LogMessage(id = 224069, value = "Change detected in broker configuration file, but reload failed", level = LogMessage.Level.ERROR)
-   void configurationReloadFailed(@Cause Throwable t);
+   void configurationReloadFailed(Throwable t);
 
    @LogMessage(id = 224072, value = "Message Counter Sample Period too short: {}", level = LogMessage.Level.WARN)
    void invalidMessageCounterPeriod(long value);
@@ -1445,7 +1444,7 @@ public interface ActiveMQServerLogger {
    void journalUseMAPPED();
 
    @LogMessage(id = 224074, value = "Failed to purge queue {} on no consumers", level = LogMessage.Level.ERROR)
-   void failedToPurgeQueue(SimpleString bindingName, @Cause Exception e);
+   void failedToPurgeQueue(SimpleString bindingName, Exception e);
 
    @LogMessage(id = 224075, value = "Cannot find pageTX id = {}", level = LogMessage.Level.ERROR)
    void journalCannotFindPageTX(Long id);
@@ -1469,19 +1468,19 @@ public interface ActiveMQServerLogger {
    void duplicateCacheSizeWarning(int idCacheSize, int confirmationWindowSize);
 
    @LogMessage(id = 224082, value = "Failed to invoke an interceptor", level = LogMessage.Level.ERROR)
-   void failedToInvokeAnInterceptor(@Cause Exception e);
+   void failedToInvokeAnInterceptor(Exception e);
 
    @LogMessage(id = 224083, value = "Failed to close context", level = LogMessage.Level.ERROR)
-   void failedToCloseContext(@Cause Exception e);
+   void failedToCloseContext(Exception e);
 
    @LogMessage(id = 224084, value = "Failed to open context", level = LogMessage.Level.ERROR)
-   void failedToOpenContext(@Cause Exception e);
+   void failedToOpenContext(Exception e);
 
    @LogMessage(id = 224085, value = "Failed to load property {}, reason: {}", level = LogMessage.Level.ERROR)
-   void failedToLoadProperty(String key, String reason, @Cause Exception e);
+   void failedToLoadProperty(String key, String reason, Exception e);
 
    @LogMessage(id = 224086, value = "Caught unexpected exception", level = LogMessage.Level.ERROR)
-   void caughtUnexpectedException(@Cause NamingException e);
+   void caughtUnexpectedException(NamingException e);
 
    @LogMessage(id = 224087, value = "Error announcing backup: backupServerLocator is null. {}", level = LogMessage.Level.ERROR)
    void errorAnnouncingBackup(String backupManager);
@@ -1490,7 +1489,7 @@ public interface ActiveMQServerLogger {
    void handshakeTimeout(int timeout, String acceptorName, String remoteAddress);
 
    @LogMessage(id = 224089, value = "Failed to calculate persistent size", level = LogMessage.Level.WARN)
-   void errorCalculatePersistentSize(@Cause Throwable e);
+   void errorCalculatePersistentSize(Throwable e);
 
    @LogMessage(id = 224090, value = "This node is not configured for Quorum Voting, all nodes must be configured for HA", level = LogMessage.Level.WARN)
    void noVoteHandlerConfigured();
@@ -1514,7 +1513,7 @@ public interface ActiveMQServerLogger {
    void failedToFindProtocolManager(String remoteAddress, String localAddress, String intendedProtocolManager, String protocolMap);
 
    @LogMessage(id = 224097, value = "Failed to start server", level = LogMessage.Level.ERROR)
-   void failedToStartServer(@Cause Throwable t);
+   void failedToStartServer(Throwable t);
 
    @LogMessage(id = 224098, value = "Received a vote saying the backup is live with connector: {}", level = LogMessage.Level.INFO)
    void quorumBackupIsLive(String liveConnector);
@@ -1538,10 +1537,10 @@ public interface ActiveMQServerLogger {
    void errorStartingAcceptor(String name, Object configuration);
 
    @LogMessage(id = 224105, value = "Connecting to cluster failed", level = LogMessage.Level.WARN)
-   void failedConnectingToCluster(@Cause Exception e);
+   void failedConnectingToCluster(Exception e);
 
    @LogMessage(id = 224106, value = "failed to remove transaction, xid:{}", level = LogMessage.Level.ERROR)
-   void errorRemovingTX(Xid xid, @Cause Exception e);
+   void errorRemovingTX(Xid xid, Exception e);
 
    @LogMessage(id = 224107, value = "The Critical Analyzer detected slow paths on the broker.  It is recommended that you enable trace logs on org.apache.activemq.artemis.utils.critical while you troubleshoot this issue. You should disable the trace logs when you have finished troubleshooting.", level = LogMessage.Level.INFO)
    void enableTraceForCriticalAnalyzer();
diff --git a/artemis-service-extensions/src/main/java/org/apache/activemq/artemis/service/extensions/xa/recovery/ActiveMQXARecoveryLogger.java b/artemis-service-extensions/src/main/java/org/apache/activemq/artemis/service/extensions/xa/recovery/ActiveMQXARecoveryLogger.java
index e9c7d87c27..05198c83ce 100644
--- a/artemis-service-extensions/src/main/java/org/apache/activemq/artemis/service/extensions/xa/recovery/ActiveMQXARecoveryLogger.java
+++ b/artemis-service-extensions/src/main/java/org/apache/activemq/artemis/service/extensions/xa/recovery/ActiveMQXARecoveryLogger.java
@@ -18,7 +18,6 @@ package org.apache.activemq.artemis.service.extensions.xa.recovery;
 
 import org.apache.activemq.artemis.api.core.client.ClientSessionFactory;
 import org.apache.activemq.artemis.logprocessor.CodeFactory;
-import org.apache.activemq.artemis.logprocessor.annotation.Cause;
 import org.apache.activemq.artemis.logprocessor.annotation.LogBundle;
 import org.apache.activemq.artemis.logprocessor.annotation.LogMessage;
 import org.w3c.dom.Node;
@@ -49,28 +48,28 @@ public interface ActiveMQXARecoveryLogger {
    void recoveryConnectFailed(String s);
 
    @LogMessage(id = 172011, value = "error unbinding {} from JNDI", level = LogMessage.Level.WARN)
-   void jndiUnbindError(String key, @Cause Exception e);
+   void jndiUnbindError(String key, Exception e);
 
    @LogMessage(id = 172012, value = "JMS Server Manager error", level = LogMessage.Level.WARN)
-   void jmsServerError(@Cause Exception e);
+   void jmsServerError(Exception e);
 
    @LogMessage(id = 172013, value = "Error in XA Recovery recover", level = LogMessage.Level.WARN)
-   void xaRecoverError(@Cause Exception e);
+   void xaRecoverError(Exception e);
 
    @LogMessage(id = 172014, value = "Notified of connection failure in xa recovery connectionFactory for provider {} will attempt reconnect on next pass",
       level = LogMessage.Level.WARN)
-   void xaRecoverConnectionError(ClientSessionFactory csf, @Cause Exception e);
+   void xaRecoverConnectionError(ClientSessionFactory csf, Exception e);
 
    @LogMessage(id = 172015, value = "Can not connect to {} on auto-generated resource recovery",
       level = LogMessage.Level.WARN)
-   void xaRecoverAutoConnectionError(XARecoveryConfig csf, @Cause Throwable e);
+   void xaRecoverAutoConnectionError(XARecoveryConfig csf, Throwable e);
 
    @LogMessage(id = 172016, value = "Error in XA Recovery", level = LogMessage.Level.DEBUG)
-   void xaRecoveryError(@Cause Exception e);
+   void xaRecoveryError(Exception e);
 
    @LogMessage(id = 172017, value = "Tried to correct invalid \"host\" value \"0.0.0.0\" for \"{}\" connector, but received an exception.",
       level = LogMessage.Level.WARN)
-   void failedToCorrectHost(String name, @Cause Exception e);
+   void failedToCorrectHost(String name, Exception e);
 
    @LogMessage(id = 172018, value = "Could not start recovery discovery on {}, we will retry every recovery scan until the server is available",
       level = LogMessage.Level.WARN)
@@ -80,5 +79,5 @@ public interface ActiveMQXARecoveryLogger {
    void jmsConfigMissingKey(Node e);
 
    @LogMessage(id = 174002, value = "Failed to start JMS deployer", level = LogMessage.Level.ERROR)
-   void jmsDeployerStartError(@Cause Exception e);
+   void jmsDeployerStartError(Exception e);
 }