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/22 17:52:14 UTC

[activemq-artemis] 20/42: remove now-unnecessary quote escaping from log/message bundle format strings, giving same output as before switch to slf4j formatter

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

commit d2faca81a3f18f572f5426954e9f1d2e4ef63bca
Author: Robbie Gemmell <ro...@apache.org>
AuthorDate: Fri Jul 15 12:37:32 2022 +0100

    remove now-unnecessary quote escaping from log/message bundle format strings, giving same output as before switch to slf4j formatter
---
 .../artemis/core/client/ActiveMQClientLogger.java  |  4 +--
 .../core/client/ActiveMQClientMessageBundle.java   |  8 ++---
 .../jms/client/ActiveMQJMSClientBundle.java        |  2 +-
 .../jms/client/ActiveMQJMSClientLogger.java        |  2 +-
 .../jms/server/ActiveMQJMSServerBundle.java        |  4 +--
 .../artemis/journal/ActiveMQJournalLogger.java     |  4 +--
 .../stomp/ActiveMQStompProtocolMessageBundle.java  |  4 +--
 .../activemq/artemis/rest/ActiveMQRestLogger.java  |  2 +-
 .../artemis/core/server/ActiveMQMessageBundle.java | 25 ++++++++--------
 .../artemis/core/server/ActiveMQServerLogger.java  | 34 +++++++++++-----------
 10 files changed, 44 insertions(+), 45 deletions(-)

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 c35e4fab22..2389dabbe9 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
@@ -176,7 +176,7 @@ public interface ActiveMQClientLogger {
    @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);
 
-   @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)
+   @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);
 
    /**
@@ -259,7 +259,7 @@ public interface ActiveMQClientLogger {
    @LogMessage(id = 212079, value = "The upstream connector from the downstream federation will ignore url parameter {}", level = LogMessage.Level.WARN)
    void ignoredParameterForDownstreamFederation(String name);
 
-   @LogMessage(id = 212080, value = "Using legacy SSL store provider value: {}. Please use either ''keyStoreType'' or ''trustStoreType'' instead as appropriate.", level = LogMessage.Level.WARN)
+   @LogMessage(id = 212080, value = "Using legacy SSL store provider value: {}. Please use either 'keyStoreType' or 'trustStoreType' instead as appropriate.", level = LogMessage.Level.WARN)
    void oldStoreProvider(String value);
 
    @LogMessage(id = 214000, value = "Failed to call onMessage", level = LogMessage.Level.ERROR)
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 753b46fa06..41970dbe72 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
@@ -198,16 +198,16 @@ public interface ActiveMQClientMessageBundle {
    @Message(id = 219051, value = "nodes have a different number of children")
    IllegalArgumentException nodeHasDifferentChildNumber();
 
-   @Message(id = 219052, value = "Element {} requires a valid Boolean value, but ''{}'' cannot be parsed as a Boolean")
+   @Message(id = 219052, value = "Element {} requires a valid Boolean value, but '{}' cannot be parsed as a Boolean")
    IllegalArgumentException mustBeBoolean(Node elem, String value);
 
-   @Message(id = 219053, value = "Element {} requires a valid Double value, but ''{}'' cannot be parsed as a Double")
+   @Message(id = 219053, value = "Element {} requires a valid Double value, but '{}' cannot be parsed as a Double")
    IllegalArgumentException mustBeDouble(Node elem, String value);
 
-   @Message(id = 219054, value = "Element {} requires a valid Integer value, but ''{}'' cannot be parsed as an Integer")
+   @Message(id = 219054, value = "Element {} requires a valid Integer value, but '{}' cannot be parsed as an Integer")
    IllegalArgumentException mustBeInteger(Node elem, String value);
 
-   @Message(id = 219055, value = "Element {} requires a valid Long value, but ''{}'' cannot be parsed as a Long")
+   @Message(id = 219055, value = "Element {} requires a valid Long value, but '{}' cannot be parsed as a Long")
    IllegalArgumentException mustBeLong(Node element, String value);
 
    @Message(id = 219057, value = "Error decoding password")
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 d7db959e63..cb376888d7 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
@@ -81,7 +81,7 @@ public interface ActiveMQJMSClientBundle {
    @Message(id = 139011, value = "LargeMessage streaming is only possible on ByteMessage or StreamMessage")
    IllegalStateException onlyValidForByteOrStreamMessages();
 
-   @Message(id = 139012, value = "The property name ''{}'' is not a valid java identifier.")
+   @Message(id = 139012, value = "The property name '{}' is not a valid java identifier.")
    JMSRuntimeException invalidJavaIdentifier(String propertyName);
 
    @Message(id = 139013, value = "Message is read-only")
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 6ff4281a93..f2f81030ba 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
@@ -40,7 +40,7 @@ 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)
+   @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);
 
    @LogMessage(id = 132001, value = "Unhandled exception thrown from onMessage", level = LogMessage.Level.WARN)
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 a53ec42c8d..2caf27c0cc 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
@@ -35,13 +35,13 @@ public interface ActiveMQJMSServerBundle {
    @Message(id = 129000, value = "Connection Factory {} does not exist")
    ActiveMQInternalErrorException cfDoesntExist(String name);
 
-   @Message(id = 129003, value = "Discovery Group ''{}'' does not exist on main config")
+   @Message(id = 129003, value = "Discovery Group '{}' does not exist on main config")
    ActiveMQIllegalStateException discoveryGroupDoesntExist(String name);
 
    @Message(id = 129004, value = "No Connector name configured on create ConnectionFactory")
    ActiveMQIllegalStateException noConnectorNameOnCF();
 
-   @Message(id = 129005, value = "Connector ''{}'' not found on the main configuration file")
+   @Message(id = 129005, value = "Connector '{}' not found on the main configuration file")
    ActiveMQIllegalStateException noConnectorNameConfiguredOnCF(String name);
 
    @Message(id = 129006, value = "Binding {} is already being used by another connection factory")
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 0e8cfceea8..75f8826283 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
@@ -99,7 +99,7 @@ public interface ActiveMQJournalLogger {
    @LogMessage(id = 142011, value = "Error on reading compacting for {}", level = LogMessage.Level.WARN)
    void compactReadError(JournalFile file);
 
-   @LogMessage(id = 142012, value = "Couldn''t find tx={} to merge after compacting", level = LogMessage.Level.WARN)
+   @LogMessage(id = 142012, value = "Couldn't find tx={} to merge after compacting", level = LogMessage.Level.WARN)
    void compactMergeError(Long id);
 
    @LogMessage(id = 142013, value = "Prepared transaction {} was not considered completed, it will be ignored", level = LogMessage.Level.WARN)
@@ -132,7 +132,7 @@ public interface ActiveMQJournalLogger {
    @LogMessage(id = 142022, value = "Timed out on AIO poller shutdown", level = LogMessage.Level.WARN)
    void timeoutOnPollerShutdown(@Cause Exception e);
 
-   @LogMessage(id = 142023, value = "Executor on file {} couldn''t complete its tasks in 60 seconds.", level = LogMessage.Level.WARN)
+   @LogMessage(id = 142023, value = "Executor on file {} couldn't complete its tasks in 60 seconds.", level = LogMessage.Level.WARN)
    void couldNotCompleteTask(@Cause Exception e, String name);
 
    @LogMessage(id = 142024, value = "Error completing callback", level = LogMessage.Level.WARN)
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 05fef2d556..a5f5bf4977 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
@@ -141,10 +141,10 @@ public interface ActiveMQStompProtocolMessageBundle {
    @Message(id = 339034, value = "This method should not be called")
    IllegalStateException invalidCall();
 
-   @Message(id = 339035, value = "Must specify the subscription''s id or the destination you are unsubscribing from")
+   @Message(id = 339035, value = "Must specify the subscription's id or the destination you are unsubscribing from")
    ActiveMQStompException needIDorDestination();
 
-   @Message(id = 339037, value = "Must specify the subscription''s id")
+   @Message(id = 339037, value = "Must specify the subscription's id")
    ActiveMQStompException needSubscriptionID();
 
    @Message(id = 339039, value = "No id header in ACK/NACK frame.")
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 30bf690082..3ae22311f8 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
@@ -53,7 +53,7 @@ public interface ActiveMQRestLogger {
    @LogMessage(id = 182003, value = "Failed to build Message from object", level = LogMessage.Level.WARN)
    void failedToBuildMessageFromObject(@Cause Exception e);
 
-   @LogMessage(id = 182004, value = "REST configuration parameter ''{}'' is deprecated. Use ''{1}'' instead.", level = LogMessage.Level.WARN)
+   @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)
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 338cb5e397..f5f75054a3 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
@@ -91,8 +91,7 @@ public interface ActiveMQMessageBundle {
    @Message(id = 229005, value = "connections for {} closed by management")
    ActiveMQInternalErrorException connectionsClosedByManagement(String ipAddress);
 
-   // TODO: replace now-unecessary '' escapes in messages with just ', throughout the codebase...in order to maintain prior output, and make the code seem less whack :/
-   @Message(id = 229006, value = "journals are not JournalImpl. You can''t set a replicator!")
+   @Message(id = 229006, value = "journals are not JournalImpl. You can't set a replicator!")
    ActiveMQInternalErrorException notJournalImpl();
 
    @Message(id = 229007, value = "unhandled error during replication")
@@ -155,10 +154,10 @@ public interface ActiveMQMessageBundle {
    @Message(id = 229027, value = "Could not find reference on consumer ID={}, messageId = {} queue = {}")
    ActiveMQIllegalStateException consumerNoReference(Long id, Long messageID, SimpleString name);
 
-   @Message(id = 229028, value = "Consumer {} doesn''t exist on the server")
+   @Message(id = 229028, value = "Consumer {} doesn't exist on the server")
    ActiveMQIllegalStateException consumerDoesntExist(long consumerID);
 
-   @Message(id = 229029, value = "No address configured on the Server''s Session")
+   @Message(id = 229029, value = "No address configured on the Server's Session")
    ActiveMQIllegalStateException noAddress();
 
    @Message(id = 229030, value = "large-message not initialized on server")
@@ -290,13 +289,13 @@ public interface ActiveMQMessageBundle {
    @Message(id = 229074, value = "Error instantiating transformer class {}")
    IllegalArgumentException errorCreatingTransformerClass(@Cause Exception e, String transformerClassName);
 
-   @Message(id = 229075, value = "method autoEncode doesn''t know how to convert {} yet")
+   @Message(id = 229075, value = "method autoEncode doesn't know how to convert {} yet")
    IllegalArgumentException autoConvertError(Class<? extends Object> aClass);
 
    /**
     * Message used on on {@link org.apache.activemq.artemis.core.server.impl.ActiveMQServerImpl#destroyConnectionWithSessionMetadata(String, String)}
     */
-   @Message(id = 229076, value = "Executing destroyConnection with {}={} through management''s request")
+   @Message(id = 229076, value = "Executing destroyConnection with {}={} through management's request")
    String destroyConnectionWithSessionMetadataHeader(String key, String value);
 
    /**
@@ -308,7 +307,7 @@ public interface ActiveMQMessageBundle {
    /**
     * Exception used on on {@link org.apache.activemq.artemis.core.server.impl.ActiveMQServerImpl#destroyConnectionWithSessionMetadata(String, String)}
     */
-   @Message(id = 229078, value = "Disconnected per admin''s request on {}={}")
+   @Message(id = 229078, value = "Disconnected per admin's request on {}={}")
    ActiveMQDisconnectedException destroyConnectionWithSessionMetadataSendException(String key, String value);
 
    /**
@@ -360,10 +359,10 @@ public interface ActiveMQMessageBundle {
    @Message(id = 229109, value = "unsupported HA Policy Configuration {}")
    ActiveMQIllegalStateException unsupportedHAPolicyConfiguration(Object o);
 
-   @Message(id = 229110, value = "Too many sessions for user ''{}''. Sessions allowed: {}.")
+   @Message(id = 229110, value = "Too many sessions for user '{}'. Sessions allowed: {}.")
    ActiveMQSessionCreationException sessionLimitReached(String username, int limit);
 
-   @Message(id = 229111, value = "Too many queues created by user ''{}''. Queues allowed: {}.")
+   @Message(id = 229111, value = "Too many queues created by user '{}'. Queues allowed: {}.")
    ActiveMQSecurityException queueLimitReached(String username, int limit);
 
    @Message(id = 229112, value = "Cannot set MBeanServer during startup or while started")
@@ -375,7 +374,7 @@ public interface ActiveMQMessageBundle {
    @Message(id = 229114, value = "Replication synchronization process timed out after waiting {} milliseconds")
    ActiveMQReplicationTimeooutException replicationSynchronizationTimeout(long timeout);
 
-   @Message(id = 229115, value = "Colocated Policy hasn''t different type live and backup")
+   @Message(id = 229115, value = "Colocated Policy hasn't different type live and backup")
    ActiveMQIllegalStateException liveBackupMismatch();
 
    @Message(id = 229116, value = "Netty Acceptor unavailable")
@@ -422,13 +421,13 @@ public interface ActiveMQMessageBundle {
    @Message(id = 229208, value = "Invalid routing type {}")
    IllegalArgumentException invalidRoutingType(String val);
 
-   @Message(id = 229209, value = "Can''t remove routing type {}, queues exists for address: {}. Please delete queues before removing this routing type.")
+   @Message(id = 229209, value = "Can't remove routing type {}, queues exists for address: {}. Please delete queues before removing this routing type.")
    IllegalStateException invalidRoutingTypeDelete(RoutingType routingType, String address);
 
-   @Message(id = 229210, value = "Can''t update queue {} with maxConsumers: {}. Current consumers are {}.")
+   @Message(id = 229210, value = "Can't update queue {} with maxConsumers: {}. Current consumers are {}.")
    IllegalStateException invalidMaxConsumersUpdate(String queueName, int maxConsumers, int consumers);
 
-   @Message(id = 229211, value = "Can''t update queue {} with routing type: {}, Supported routing types for address: {} are {}")
+   @Message(id = 229211, value = "Can't update queue {} with routing type: {}, Supported routing types for address: {} are {}")
    IllegalStateException invalidRoutingTypeUpdate(String queueName,
                                                   RoutingType routingType,
                                                   String address,
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 2aca599e5e..bc2ed282ac 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
@@ -195,10 +195,10 @@ public interface ActiveMQServerLogger {
                                SimpleString address,
                                SimpleString simpleString);
 
-   @LogMessage(id = 221037, value = "{} to become ''live''", level = LogMessage.Level.INFO)
+   @LogMessage(id = 221037, value = "{} to become 'live'", level = LogMessage.Level.INFO)
    void becomingLive(ActiveMQServer server);
 
-   @LogMessage(id = 221038, value = "Configuration option ''{}'' is deprecated. Consult the manual for details.", level = LogMessage.Level.INFO)
+   @LogMessage(id = 221038, value = "Configuration option '{}' is deprecated. Consult the manual for details.", level = LogMessage.Level.INFO)
    void deprecatedConfigurationOption(String deprecatedOption);
 
    @LogMessage(id = 221039, value = "Restarting as Replicating backup server after live restart", level = LogMessage.Level.INFO)
@@ -219,13 +219,13 @@ public interface ActiveMQServerLogger {
    @LogMessage(id = 221045, value = "libaio is not available, switching the configuration into NIO", level = LogMessage.Level.INFO)
    void switchingNIO();
 
-   @LogMessage(id = 221046, value = "Unblocking message production on address ''{}''; {}", level = LogMessage.Level.INFO)
+   @LogMessage(id = 221046, value = "Unblocking message production on address '{}'; {}", level = LogMessage.Level.INFO)
    void unblockingMessageProduction(SimpleString addressName, String sizeInfo);
 
    @LogMessage(id = 221047, value = "Backup Server has scaled down to live server", level = LogMessage.Level.INFO)
    void backupServerScaledDown();
 
-   @LogMessage(id = 221048, value = "Consumer {}:{} attached to queue ''{}'' from {} identified as ''slow.'' Expected consumption rate: {} msgs/second; actual consumption rate: {} msgs/second.", level = LogMessage.Level.INFO)
+   @LogMessage(id = 221048, value = "Consumer {}:{} attached to queue '{}' from {} identified as 'slow.' Expected consumption rate: {} msgs/second; actual consumption rate: {} msgs/second.", level = LogMessage.Level.INFO)
    void slowConsumerDetected(String sessionID,
                              long consumerID,
                              String queueName,
@@ -245,7 +245,7 @@ public interface ActiveMQServerLogger {
    @LogMessage(id = 221052, value = "Deploying topic {}", level = LogMessage.Level.INFO)
    void deployTopic(SimpleString topicName);
 
-   @LogMessage(id = 221053, value = "Disallowing use of vulnerable protocol ''{}'' on acceptor ''{}''. See http://www.oracle.com/technetwork/topics/security/poodlecve-2014-3566-2339408.html for more details.", level = LogMessage.Level.INFO)
+   @LogMessage(id = 221053, value = "Disallowing use of vulnerable protocol '{}' on acceptor '{}'. See http://www.oracle.com/technetwork/topics/security/poodlecve-2014-3566-2339408.html for more details.", level = LogMessage.Level.INFO)
    void disallowedProtocol(String protocol, String acceptorName);
 
    @LogMessage(id = 221054, value = "libaio was found but the filesystem does not support AIO. Switching the configuration into NIO. Journal path: {}", level = LogMessage.Level.INFO)
@@ -401,7 +401,7 @@ public interface ActiveMQServerLogger {
    @LogMessage(id = 222019, value = "There is already a discovery group with name {} deployed. This one will not be deployed.", level = LogMessage.Level.WARN)
    void discoveryGroupAlreadyDeployed(String name);
 
-   @LogMessage(id = 222020, value = "error scanning for URL''s", level = LogMessage.Level.WARN)
+   @LogMessage(id = 222020, value = "error scanning for URL's", level = LogMessage.Level.WARN)
    void errorScanningURLs(@Cause Exception e);
 
    @LogMessage(id = 222021, value = "problem undeploying {}", level = LogMessage.Level.WARN)
@@ -455,10 +455,10 @@ public interface ActiveMQServerLogger {
    @LogMessage(id = 222037, value = "IO Error, impossible to start paging", level = LogMessage.Level.WARN)
    void pageStoreStartIOError(@Cause Exception e);
 
-   @LogMessage(id = 222038, value = "Starting paging on address ''{}''; {}", level = LogMessage.Level.INFO)
+   @LogMessage(id = 222038, value = "Starting paging on address '{}'; {}", level = LogMessage.Level.INFO)
    void pageStoreStart(SimpleString storeName, String sizeInfo);
 
-   @LogMessage(id = 222039, value = "Messages sent to address ''{}'' are being dropped; {}", level = LogMessage.Level.WARN)
+   @LogMessage(id = 222039, value = "Messages sent to address '{}' are being dropped; {}", level = LogMessage.Level.WARN)
    void pageStoreDropMessages(SimpleString storeName, String sizeInfo);
 
    @LogMessage(id = 222040, value = "Server is stopped", level = LogMessage.Level.WARN)
@@ -828,13 +828,13 @@ public interface ActiveMQServerLogger {
    void groupingQueueRemoved(int size, SimpleString clusterName);
 
    @SuppressWarnings("deprecation")
-   @LogMessage(id = 222168, value = "The ''" + TransportConstants.PROTOCOL_PROP_NAME + "'' property is deprecated. If you want this Acceptor to support multiple protocols, use the ''" + TransportConstants.PROTOCOLS_PROP_NAME + "'' property, e.g. with value ''CORE,AMQP,STOMP''", level = LogMessage.Level.WARN)
+   @LogMessage(id = 222168, value = "The '" + TransportConstants.PROTOCOL_PROP_NAME + "' property is deprecated. If you want this Acceptor to support multiple protocols, use the '" + TransportConstants.PROTOCOLS_PROP_NAME + "' property, e.g. with value 'CORE,AMQP,STOMP'", level = LogMessage.Level.WARN)
    void warnDeprecatedProtocol();
 
-   @LogMessage(id = 222169, value = "You have old legacy clients connected to the queue {} and we can''t disconnect them, these clients may just hang", level = LogMessage.Level.WARN)
+   @LogMessage(id = 222169, value = "You have old legacy clients connected to the queue {} and we can't disconnect them, these clients may just hang", level = LogMessage.Level.WARN)
    void warnDisconnectOldClient(String queueName);
 
-   @LogMessage(id = 222170, value = "Bridge {} forwarding address {} has confirmation-window-size ({}) greater than address'' max-size-bytes'' ({})", level = LogMessage.Level.WARN)
+   @LogMessage(id = 222170, value = "Bridge {} forwarding address {} has confirmation-window-size ({}) greater than address' max-size-bytes' ({})", level = LogMessage.Level.WARN)
    void bridgeConfirmationWindowTooSmall(String bridgeName, String address, int windowConfirmation, long maxSizeBytes);
 
    @LogMessage(id = 222171, value = "Bridge {} forwarding address {} could not be resolved on address-settings configuration", level = LogMessage.Level.WARN)
@@ -867,7 +867,7 @@ public interface ActiveMQServerLogger {
    @LogMessage(id = 222182, value = "Missing cluster-configuration for scale-down-clustername {}", level = LogMessage.Level.WARN)
    void missingClusterConfigForScaleDown(String scaleDownCluster);
 
-   @LogMessage(id = 222183, value = "Blocking message production on address ''{}''; {}", level = LogMessage.Level.WARN)
+   @LogMessage(id = 222183, value = "Blocking message production on address '{}'; {}", level = LogMessage.Level.WARN)
    void blockingMessageProduction(SimpleString addressName, String pageInfo);
 
    @LogMessage(id = 222184, value = "Unable to recover group bindings in SCALE_DOWN mode, only FULL backup server can do this", level = LogMessage.Level.WARN)
@@ -900,7 +900,7 @@ public interface ActiveMQServerLogger {
    @LogMessage(id = 222194, value = "PageCursorInfo == null on address {}, pos = {}, queue = {}.", level = LogMessage.Level.WARN)
    void nullPageCursorInfo(String address, String position, long id);
 
-   @LogMessage(id = 222195, value = "Large message {} wasn''t found when dealing with add pending large message", level = LogMessage.Level.WARN)
+   @LogMessage(id = 222195, value = "Large message {} wasn't found when dealing with add pending large message", level = LogMessage.Level.WARN)
    void largeMessageNotFound(long id);
 
    @LogMessage(id = 222196, value = "Could not find binding with id={} on routeFromCluster for message={} binding = {}", level = LogMessage.Level.WARN)
@@ -954,7 +954,7 @@ public interface ActiveMQServerLogger {
    @LogMessage(id = 222211, value = "Free storage space is at {} of {} total. Usage rate is {} which is below the configured <max-disk-usage>.", level = LogMessage.Level.INFO)
    void diskCapacityRestored(String usableSpace, String totalSpace, String usage);
 
-   @LogMessage(id = 222212, value = "Disk Full! Blocking message production on address ''{}''. Clients will report blocked.", level = LogMessage.Level.WARN)
+   @LogMessage(id = 222212, value = "Disk Full! Blocking message production on address '{}'. Clients will report blocked.", level = LogMessage.Level.WARN)
    void blockingDiskFull(SimpleString addressName);
 
    @LogMessage(id = 222213, value = "There was an issue on the network, server is isolated!", level = LogMessage.Level.WARN)
@@ -1546,7 +1546,7 @@ public interface ActiveMQServerLogger {
    @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();
 
-   @LogMessage(id = 224108, value = "Stopped paging on address ''{}''; {}", level = LogMessage.Level.INFO)
+   @LogMessage(id = 224108, value = "Stopped paging on address '{}'; {}", level = LogMessage.Level.INFO)
    void pageStoreStop(SimpleString storeName, String pageInfo);
 
    @LogMessage(id = 224109, value = "ConnectionRouter {} not found", level = LogMessage.Level.WARN)
@@ -1564,10 +1564,10 @@ public interface ActiveMQServerLogger {
    @LogMessage(id = 224113, value = "Auto removing Address {}", level = LogMessage.Level.INFO)
    void autoRemoveAddress(String name);
 
-   @LogMessage(id = 224114, value = "Address control block, blocking message production on address ''{}''. Clients will not get further credit.", level = LogMessage.Level.INFO)
+   @LogMessage(id = 224114, value = "Address control block, blocking message production on address '{}'. Clients will not get further credit.", level = LogMessage.Level.INFO)
    void blockingViaControl(SimpleString addressName);
 
-   @LogMessage(id = 224115, value = "Address control unblock of address ''{}''. Clients will be granted credit as normal.", level = LogMessage.Level.INFO)
+   @LogMessage(id = 224115, value = "Address control unblock of address '{}'. Clients will be granted credit as normal.", level = LogMessage.Level.INFO)
    void unblockingViaControl(SimpleString addressName);
 
    @LogMessage(id = 224116, value = "The component {} is not responsive during start up. The Server may be taking too long to start", level = LogMessage.Level.WARN)