You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@camel.apache.org by or...@apache.org on 2023/08/08 14:29:28 UTC

[camel] branch main updated: (chores) Adjusted components A to F to use log markers (#11045)

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

orpiske pushed a commit to branch main
in repository https://gitbox.apache.org/repos/asf/camel.git


The following commit(s) were added to refs/heads/main by this push:
     new 11c33fb292d (chores) Adjusted components A to F to use log markers (#11045)
11c33fb292d is described below

commit 11c33fb292d66eaab9880c22b12aa543b51bbe09
Author: Otavio Rodolfo Piske <or...@users.noreply.github.com>
AuthorDate: Tue Aug 8 16:29:21 2023 +0200

    (chores) Adjusted components A to F to use log markers (#11045)
---
 .../camel/component/as2/api/util/MicUtilsTest.java |  4 +--
 .../as2/internal/AS2ConnectionHelper.java          |  5 ++-
 .../camel/component/as2/AS2ClientManagerIT.java    | 14 ++++----
 .../camel/component/as2/AS2ServerManagerIT.java    | 10 +++---
 .../camel/component/as2/MendelsonCertLoader.java   |  8 ++---
 .../component/asterisk/AsteriskConsumerTest.java   |  2 +-
 .../websocket/CamelWebSocketServlet.java           |  2 +-
 .../vault/CloudTrailReloadTriggerTask.java         |  5 ++-
 .../camel/component/aws/xray/FakeAWSDaemon.java    |  4 +--
 .../camel/component/file/azure/FilesConsumer.java  |  3 +-
 .../src/main/docs/bindy-dataformat.adoc            |  4 +--
 .../BindySimpleCsvUnmarshallBadIntegerTest.java    |  2 +-
 .../BindyComplexKeyValuePairStandaloneTest.java    |  4 +--
 .../component/box/BoxCollaborationsManagerIT.java  | 12 +++----
 .../camel/component/box/BoxCommentsManagerIT.java  | 10 +++---
 .../camel/component/box/BoxEventLogsManagerIT.java |  2 +-
 .../camel/component/box/BoxEventsManagerIT.java    |  2 +-
 .../camel/component/box/BoxFilesManagerIT.java     | 38 +++++++++++-----------
 .../camel/component/box/BoxFoldersManagerIT.java   | 20 ++++++------
 .../camel/component/box/BoxGroupsManagerIT.java    | 16 ++++-----
 .../camel/component/box/BoxSearchManagerIT.java    |  2 +-
 .../camel/component/box/BoxTasksManagerIT.java     | 14 ++++----
 .../camel/component/box/BoxUsersManagerIT.java     | 16 ++++-----
 .../camel/component/braintree/AddOnGatewayIT.java  |  2 +-
 .../braintree/CreditCardVerificationGatewayIT.java |  4 +--
 .../component/braintree/DiscountGatewayIT.java     |  2 +-
 .../braintree/PaymentMethodNonceGatewayIT.java     |  4 +--
 .../camel/component/braintree/PlanGatewayIT.java   |  2 +-
 .../camel/component/braintree/ReportGatewayIT.java |  2 +-
 .../braintree/SettlementBatchSummaryGatewayIT.java |  4 +--
 .../component/braintree/SubscriptionGatewayIT.java | 16 ++++-----
 .../component/braintree/TransactionGatewayIT.java  | 14 ++++----
 .../camel/component/crypto/ECDSASignatureTest.java |  2 +-
 .../apache/camel/dataformat/csv/CsvRouteTest.java  |  6 ++--
 .../language/datasonnet/DatasonnetExpression.java  |  2 +-
 .../src/main/docs/debezium-db2-component.adoc      |  8 ++---
 .../src/main/docs/debezium-mysql-component.adoc    |  8 ++---
 .../src/main/docs/debezium-oracle-component.adoc   |  8 ++---
 .../src/main/docs/debezium-postgres-component.adoc |  8 ++---
 .../main/docs/debezium-sqlserver-component.adoc    |  8 ++---
 .../camel/component/debug/JmxConnectorService.java |  2 +-
 .../DirectRequestReplyAndDisruptorInOnlyTest.java  |  2 +-
 .../component/disruptor/DisruptorRouteTest.java    |  4 +--
 .../apache/camel/component/exec/ExecTestUtils.java |  2 +-
 .../camel/component/fhir/FhirCapabilitiesIT.java   |  4 +--
 .../apache/camel/component/fhir/FhirCreateIT.java  |  6 ++--
 .../apache/camel/component/fhir/FhirDeleteIT.java  | 10 +++---
 .../component/fhir/FhirExtraParametersIT.java      |  2 +-
 .../apache/camel/component/fhir/FhirHistoryIT.java |  8 ++---
 .../camel/component/fhir/FhirLoadPageIT.java       |  8 ++---
 .../apache/camel/component/fhir/FhirMetaIT.java    | 12 +++----
 .../camel/component/fhir/FhirOperationIT.java      |  8 ++---
 .../apache/camel/component/fhir/FhirPatchIT.java   |  4 +--
 .../apache/camel/component/fhir/FhirReadIT.java    |  2 +-
 .../apache/camel/component/fhir/FhirSearchIT.java  |  2 +-
 .../camel/component/fhir/FhirTransactionIT.java    |  8 ++---
 .../apache/camel/component/fhir/FhirUpdateIT.java  | 14 ++++----
 .../camel/component/fhir/FhirValidateIT.java       |  4 +--
 ...dempotentChangedRepositoryReadLockStrategy.java |  2 +-
 ...IdempotentRenameRepositoryReadLockStrategy.java |  2 +-
 .../FileIdempotentRepositoryReadLockStrategy.java  |  2 +-
 .../camel/component/flatpack/CharsetTest.java      |  2 +-
 .../component/flatpack/DelimitedAllowLongTest.java |  2 +-
 .../flatpack/DelimitedAllowShortAndLongTest.java   |  2 +-
 .../flatpack/DelimitedAllowShortTest.java          |  2 +-
 .../camel/component/flatpack/DelimitedTest.java    |  2 +-
 .../flatpack/DelimitedWithNoDescriptorTest.java    |  2 +-
 .../flatpack/DelimitedWithUnmarshalTest.java       |  2 +-
 .../flatpack/FixedLengthAllowLongTest.java         |  2 +-
 .../flatpack/FixedLengthAllowShortAndLongTest.java |  2 +-
 .../flatpack/FixedLengthAllowShortTest.java        |  2 +-
 .../camel/component/flatpack/FixedLengthTest.java  |  2 +-
 .../flatpack/FixedLengthWithUnmarshalTest.java     |  2 +-
 .../component/flatpack/HeaderAndTrailerTest.java   |  2 +-
 .../camel/component/flatpack/NoSplitRowsTest.java  |  2 +-
 .../component/flatpack/StreamedSplitTest.java      |  2 +-
 .../component/flatpack/XMLNoSplitRowsTest.java     |  2 +-
 .../camel/component/flatpack/XMLSplitRowsTest.java |  2 +-
 .../component/file/remote/SftpOperations.java      |  2 +-
 .../FromFtpExclusiveReadNoneStrategyIT.java        |  2 +-
 .../remote/integration/FtpChangedReadLockIT.java   |  2 +-
 .../integration/FtpChangedRootDirReadLockIT.java   |  2 +-
 .../sftp/integration/SftpChangedReadLockIT.java    |  2 +-
 83 files changed, 224 insertions(+), 227 deletions(-)

diff --git a/components/camel-as2/camel-as2-api/src/test/java/org/apache/camel/component/as2/api/util/MicUtilsTest.java b/components/camel-as2/camel-as2-api/src/test/java/org/apache/camel/component/as2/api/util/MicUtilsTest.java
index ad85477c12d..3ab269da4e7 100644
--- a/components/camel-as2/camel-as2-api/src/test/java/org/apache/camel/component/as2/api/util/MicUtilsTest.java
+++ b/components/camel-as2/camel-as2-api/src/test/java/org/apache/camel/component/as2/api/util/MicUtilsTest.java
@@ -103,10 +103,10 @@ public class MicUtilsTest {
 
         ReceivedContentMic receivedContentMic = MicUtils.createReceivedContentMic(request, null, null);
         assertNotNull(receivedContentMic, "Failed to create Received Content MIC");
-        LOG.debug("Digest Algorithm: " + receivedContentMic.getDigestAlgorithmId());
+        LOG.debug("Digest Algorithm: {}", receivedContentMic.getDigestAlgorithmId());
         assertEquals(EXPECTED_MESSAGE_DIGEST_ALGORITHM, receivedContentMic.getDigestAlgorithmId(),
                 "Unexpected digest algorithm value");
-        LOG.debug("Encoded Message Digest: " + receivedContentMic.getEncodedMessageDigest());
+        LOG.debug("Encoded Message Digest: {}", receivedContentMic.getEncodedMessageDigest());
         assertEquals(EXPECTED_ENCODED_MESSAGE_DIGEST, receivedContentMic.getEncodedMessageDigest(),
                 "Unexpected encoded message digest value");
     }
diff --git a/components/camel-as2/camel-as2-component/src/main/java/org/apache/camel/component/as2/internal/AS2ConnectionHelper.java b/components/camel-as2/camel-as2-component/src/main/java/org/apache/camel/component/as2/internal/AS2ConnectionHelper.java
index b99ebec65c4..f4b8b2f5ac0 100644
--- a/components/camel-as2/camel-as2-component/src/main/java/org/apache/camel/component/as2/internal/AS2ConnectionHelper.java
+++ b/components/camel-as2/camel-as2-component/src/main/java/org/apache/camel/component/as2/internal/AS2ConnectionHelper.java
@@ -92,9 +92,8 @@ public final class AS2ConnectionHelper {
                     conn.close();
                 } catch (Exception e) {
                     // ignore
-                    LOG.debug("Error stopping and closing AS2ServerConnection due to " + e.getMessage()
-                              + ". This exception is ignored",
-                            e);
+                    LOG.debug("Error stopping and closing AS2ServerConnection due to {}. This exception is ignored",
+                            e.getMessage(), e);
                 }
             }
         }
diff --git a/components/camel-as2/camel-as2-component/src/test/java/org/apache/camel/component/as2/AS2ClientManagerIT.java b/components/camel-as2/camel-as2-component/src/test/java/org/apache/camel/component/as2/AS2ClientManagerIT.java
index 70c80c8d4af..9b1ff394201 100644
--- a/components/camel-as2/camel-as2-component/src/test/java/org/apache/camel/component/as2/AS2ClientManagerIT.java
+++ b/components/camel-as2/camel-as2-component/src/test/java/org/apache/camel/component/as2/AS2ClientManagerIT.java
@@ -191,7 +191,7 @@ public class AS2ClientManagerIT extends AbstractAS2ITSupport {
         HttpResponse response = result.getRight();
 
         assertNotNull(result, "send result");
-        LOG.debug("send: " + result);
+        LOG.debug("send: {}", result);
         assertNotNull(request, "Request");
         assertTrue(request instanceof HttpEntityEnclosingRequest, "Request does not contain body");
         HttpEntity entity = ((HttpEntityEnclosingRequest) request).getEntity();
@@ -270,7 +270,7 @@ public class AS2ClientManagerIT extends AbstractAS2ITSupport {
         HttpResponse response = result.getRight();
 
         assertNotNull(result, "send result");
-        LOG.debug("send: " + result);
+        LOG.debug("send: {}", result);
         assertNotNull(request, "Request");
         assertTrue(request instanceof HttpEntityEnclosingRequest, "Request does not contain body");
         HttpEntity entity = ((HttpEntityEnclosingRequest) request).getEntity();
@@ -357,7 +357,7 @@ public class AS2ClientManagerIT extends AbstractAS2ITSupport {
         HttpResponse response = result.getRight();
 
         assertNotNull(result, "send result");
-        LOG.debug("send: " + result);
+        LOG.debug("send: {}", result);
 
         assertNotNull(request, "Request");
         assertTrue(request instanceof HttpEntityEnclosingRequest, "Request does not contain body");
@@ -453,7 +453,7 @@ public class AS2ClientManagerIT extends AbstractAS2ITSupport {
         HttpResponse response = result.getRight();
 
         assertNotNull(result, "send result");
-        LOG.debug("send: " + result);
+        LOG.debug("send: {}", result);
         assertNotNull(request, "Request");
         assertTrue(request instanceof HttpEntityEnclosingRequest, "Request does not contain body");
         HttpEntity entity = ((HttpEntityEnclosingRequest) request).getEntity();
@@ -563,7 +563,7 @@ public class AS2ClientManagerIT extends AbstractAS2ITSupport {
         HttpResponse response = result.getRight();
 
         assertNotNull(result, "send result");
-        LOG.debug("send: " + result);
+        LOG.debug("send: {}", result);
         assertNotNull(request, "Request");
         assertTrue(request instanceof HttpEntityEnclosingRequest, "Request does not contain body");
         HttpEntity entity = ((HttpEntityEnclosingRequest) request).getEntity();
@@ -669,7 +669,7 @@ public class AS2ClientManagerIT extends AbstractAS2ITSupport {
         HttpResponse response = result.getRight();
 
         assertNotNull(result, "send result");
-        LOG.debug("send: " + result);
+        LOG.debug("send: {}", result);
         assertNotNull(request, "Request");
         assertTrue(request instanceof HttpEntityEnclosingRequest, "Request does not contain body");
         HttpEntity entity = ((HttpEntityEnclosingRequest) request).getEntity();
@@ -815,7 +815,7 @@ public class AS2ClientManagerIT extends AbstractAS2ITSupport {
         @Override
         public void handle(HttpRequest request, HttpResponse response, HttpContext context)
                 throws HttpException, IOException {
-            LOG.info("Received test message: " + request);
+            LOG.info("Received test message: {}", request);
             context.setAttribute(AS2ServerManager.FROM, MDN_FROM);
             context.setAttribute(AS2ServerManager.SUBJECT, MDN_SUBJECT_PREFIX);
 
diff --git a/components/camel-as2/camel-as2-component/src/test/java/org/apache/camel/component/as2/AS2ServerManagerIT.java b/components/camel-as2/camel-as2-component/src/test/java/org/apache/camel/component/as2/AS2ServerManagerIT.java
index 22485cd5c24..9b2618ccb7b 100644
--- a/components/camel-as2/camel-as2-component/src/test/java/org/apache/camel/component/as2/AS2ServerManagerIT.java
+++ b/components/camel-as2/camel-as2-component/src/test/java/org/apache/camel/component/as2/AS2ServerManagerIT.java
@@ -183,7 +183,7 @@ public class AS2ServerManagerIT extends AbstractAS2ITSupport {
         final List<Exchange> exchanges = mockEndpoint.getExchanges();
         assertNotNull(exchanges, "listen result");
         assertFalse(exchanges.isEmpty(), "listen result");
-        LOG.debug("poll result: " + exchanges);
+        LOG.debug("poll result: {}", exchanges);
 
         Exchange exchange = exchanges.get(0);
         Message message = exchange.getIn();
@@ -251,7 +251,7 @@ public class AS2ServerManagerIT extends AbstractAS2ITSupport {
         final List<Exchange> exchanges = mockEndpoint.getExchanges();
         assertNotNull(exchanges, "listen result");
         assertFalse(exchanges.isEmpty(), "listen result");
-        LOG.debug("poll result: " + exchanges);
+        LOG.debug("poll result: {}", exchanges);
 
         Exchange exchange = exchanges.get(0);
         Message message = exchange.getIn();
@@ -333,7 +333,7 @@ public class AS2ServerManagerIT extends AbstractAS2ITSupport {
         final List<Exchange> exchanges = mockEndpoint.getExchanges();
         assertNotNull(exchanges, "listen result");
         assertFalse(exchanges.isEmpty(), "listen result");
-        LOG.debug("poll result: " + exchanges);
+        LOG.debug("poll result: {}", exchanges);
 
         Exchange exchange = exchanges.get(0);
         Message message = exchange.getIn();
@@ -427,7 +427,7 @@ public class AS2ServerManagerIT extends AbstractAS2ITSupport {
         final List<Exchange> exchanges = mockEndpoint.getExchanges();
         assertNotNull(exchanges, "listen result");
         assertFalse(exchanges.isEmpty(), "listen result");
-        LOG.debug("poll result: " + exchanges);
+        LOG.debug("poll result: {}", exchanges);
 
         Exchange exchange = exchanges.get(0);
         Message message = exchange.getIn();
@@ -507,7 +507,7 @@ public class AS2ServerManagerIT extends AbstractAS2ITSupport {
         final List<Exchange> exchanges = mockEndpoint.getExchanges();
         assertNotNull(exchanges, "listen result");
         assertFalse(exchanges.isEmpty(), "listen result");
-        LOG.debug("poll result: " + exchanges);
+        LOG.debug("poll result: {}", exchanges);
 
         Exchange exchange = exchanges.get(0);
         Message message = exchange.getIn();
diff --git a/components/camel-as2/camel-as2-component/src/test/java/org/apache/camel/component/as2/MendelsonCertLoader.java b/components/camel-as2/camel-as2-component/src/test/java/org/apache/camel/component/as2/MendelsonCertLoader.java
index c88b6997e9e..37216f01eca 100644
--- a/components/camel-as2/camel-as2-component/src/test/java/org/apache/camel/component/as2/MendelsonCertLoader.java
+++ b/components/camel-as2/camel-as2-component/src/test/java/org/apache/camel/component/as2/MendelsonCertLoader.java
@@ -162,21 +162,21 @@ public class MendelsonCertLoader {
         try {
             ks = KeyStore.getInstance("PKCS12");
         } catch (KeyStoreException e) {
-            LOG.error("Error while getting instance of KeyStore" + e);
+            LOG.error("Error while getting instance of KeyStore: {}", e.getMessage(), e);
         }
         try {
             ks.load(inputStream, keyStorePassword.toCharArray());
         } catch (CertificateException e) {
-            LOG.error("Error while loading the certificate" + e);
+            LOG.error("Error while loading the certificate: {}", e.getMessage(), e);
         }
         try {
             return (PrivateKey) ks.getKey(
                     ks.aliases().nextElement(),
                     keyStorePassword.toCharArray());
         } catch (KeyStoreException e) {
-            LOG.error("Error while retrieving private key" + e);
+            LOG.error("Error while retrieving private key: {}", e.getMessage(), e);
         } catch (UnrecoverableKeyException e) {
-            LOG.error("Error while retrieving private key" + e);
+            LOG.error("Error while retrieving private key: {}", e.getMessage(), e);
         }
         throw new IllegalStateException("Failed to construct a PrivateKey from provided InputStream");
     }
diff --git a/components/camel-asterisk/src/test/java/org/apache/camel/component/asterisk/AsteriskConsumerTest.java b/components/camel-asterisk/src/test/java/org/apache/camel/component/asterisk/AsteriskConsumerTest.java
index 17886ce381c..9aa03d66931 100644
--- a/components/camel-asterisk/src/test/java/org/apache/camel/component/asterisk/AsteriskConsumerTest.java
+++ b/components/camel-asterisk/src/test/java/org/apache/camel/component/asterisk/AsteriskConsumerTest.java
@@ -44,7 +44,7 @@ public class AsteriskConsumerTest extends CamelTestSupport {
         List<Exchange> events = mock.getExchanges();
         if (LOG.isInfoEnabled()) {
             for (Exchange e : events) {
-                LOG.info("ASTERISK EVENTS: " + e.getIn().getBody(String.class));
+                LOG.info("ASTERISK EVENTS: {}", e.getIn().getBody(String.class));
             }
         }
     }
diff --git a/components/camel-atmosphere-websocket/src/main/java/org/apache/camel/component/atmosphere/websocket/CamelWebSocketServlet.java b/components/camel-atmosphere-websocket/src/main/java/org/apache/camel/component/atmosphere/websocket/CamelWebSocketServlet.java
index 32cde6ffda4..228241fda64 100644
--- a/components/camel-atmosphere-websocket/src/main/java/org/apache/camel/component/atmosphere/websocket/CamelWebSocketServlet.java
+++ b/components/camel-atmosphere-websocket/src/main/java/org/apache/camel/component/atmosphere/websocket/CamelWebSocketServlet.java
@@ -54,7 +54,7 @@ public class CamelWebSocketServlet extends CamelHttpTransportServlet {
             handleDoService(request, response);
         } catch (Exception e) {
             // do not leak exception back to caller
-            log.warn("Error handling request due to: " + e.getMessage(), e);
+            log.warn("Error handling request due to: {}", e.getMessage(), e);
             try {
                 if (!response.isCommitted()) {
                     response.sendError(HttpServletResponse.SC_INTERNAL_SERVER_ERROR);
diff --git a/components/camel-aws/camel-aws-secrets-manager/src/main/java/org/apache/camel/component/aws/secretsmanager/vault/CloudTrailReloadTriggerTask.java b/components/camel-aws/camel-aws-secrets-manager/src/main/java/org/apache/camel/component/aws/secretsmanager/vault/CloudTrailReloadTriggerTask.java
index e64d993255b..3a810c218a9 100644
--- a/components/camel-aws/camel-aws-secrets-manager/src/main/java/org/apache/camel/component/aws/secretsmanager/vault/CloudTrailReloadTriggerTask.java
+++ b/components/camel-aws/camel-aws-secrets-manager/src/main/java/org/apache/camel/component/aws/secretsmanager/vault/CloudTrailReloadTriggerTask.java
@@ -245,9 +245,8 @@ public class CloudTrailReloadTriggerTask extends ServiceSupport implements Camel
                 }
             }
         } catch (Exception e) {
-            LOG.warn("Error during AWS Secrets Refresh Task due to " + e.getMessage()
-                     + ". This exception is ignored. Will try again on next run.",
-                    e);
+            LOG.warn("Error during AWS Secrets Refresh Task due to {}. This exception is ignored. Will try again on next run.",
+                    e.getMessage(), e);
         }
 
         if (triggerReloading) {
diff --git a/components/camel-aws/camel-aws-xray/src/test/java/org/apache/camel/component/aws/xray/FakeAWSDaemon.java b/components/camel-aws/camel-aws-xray/src/test/java/org/apache/camel/component/aws/xray/FakeAWSDaemon.java
index 31c1b60a929..c86ac019bbb 100644
--- a/components/camel-aws/camel-aws-xray/src/test/java/org/apache/camel/component/aws/xray/FakeAWSDaemon.java
+++ b/components/camel-aws/camel-aws-xray/src/test/java/org/apache/camel/component/aws/xray/FakeAWSDaemon.java
@@ -141,13 +141,13 @@ public class FakeAWSDaemon {
                         LOG.trace("Item {} received. JSON content: {}, Raw: {}",
                                 receivedTraces.size(), receivedTraces, raw);
                     } catch (Exception jsonEx) {
-                        LOG.warn("Could not convert segment " + locSegment + " to a Java object", jsonEx);
+                        LOG.warn("Could not convert segment {} to a Java object", locSegment, jsonEx);
                     }
                 }
             } catch (SocketException sex) {
                 LOG.info("UDP socket closed");
             } catch (Exception ex) {
-                LOG.warn("UDP socket failed due to " + ex.getLocalizedMessage(), ex);
+                LOG.warn("UDP socket failed due to {}", ex.getLocalizedMessage(), ex);
             }
         }
 
diff --git a/components/camel-azure/camel-azure-files/src/main/java/org/apache/camel/component/file/azure/FilesConsumer.java b/components/camel-azure/camel-azure-files/src/main/java/org/apache/camel/component/file/azure/FilesConsumer.java
index 85eefa20442..33efc3fcf9a 100644
--- a/components/camel-azure/camel-azure-files/src/main/java/org/apache/camel/component/file/azure/FilesConsumer.java
+++ b/components/camel-azure/camel-azure-files/src/main/java/org/apache/camel/component/file/azure/FilesConsumer.java
@@ -72,8 +72,7 @@ public class FilesConsumer extends RemoteFileConsumer<ShareFileItem> {
                     operations.buildDirectory(endpointPath, true);
                 } catch (GenericFileOperationFailedException e) {
                     // log a WARN as we want to start the consumer.
-                    LOG.warn("Error auto creating directory: " + endpointPath + " due " + e.getMessage()
-                             + ". This exception is ignored.",
+                    LOG.warn("Error auto creating directory: {} due to {}. This exception is ignored.", endpointPath, e.getMessage(),
                             e);
                 }
             }
diff --git a/components/camel-bindy/src/main/docs/bindy-dataformat.adoc b/components/camel-bindy/src/main/docs/bindy-dataformat.adoc
index 5d0b701b273..c45d121c4d7 100644
--- a/components/camel-bindy/src/main/docs/bindy-dataformat.adoc
+++ b/components/camel-bindy/src/main/docs/bindy-dataformat.adoc
@@ -1761,12 +1761,12 @@ int modelCount = 0;
 for (Map<String, Object> model : unmarshaledModels) {
   for (String className : model.keySet()) {
      Object obj = model.get(className);
-     LOG.info("Count : " + modelCount + ", " + obj.toString());
+     LOG.info("Count : {}, {}", modelCount, obj.toString());
   }
  modelCount++;
 }
 
-LOG.info("Total CSV records received by the csv bean : " + modelCount);
+LOG.info("Total CSV records received by the csv bean : {}", modelCount);
 ----
 
 Assuming that you want to extract a single Order object from this map
diff --git a/components/camel-bindy/src/test/java/org/apache/camel/dataformat/bindy/csv/BindySimpleCsvUnmarshallBadIntegerTest.java b/components/camel-bindy/src/test/java/org/apache/camel/dataformat/bindy/csv/BindySimpleCsvUnmarshallBadIntegerTest.java
index 0ba0eb0b7b4..71086a1f81b 100644
--- a/components/camel-bindy/src/test/java/org/apache/camel/dataformat/bindy/csv/BindySimpleCsvUnmarshallBadIntegerTest.java
+++ b/components/camel-bindy/src/test/java/org/apache/camel/dataformat/bindy/csv/BindySimpleCsvUnmarshallBadIntegerTest.java
@@ -66,7 +66,7 @@ public class BindySimpleCsvUnmarshallBadIntegerTest {
 
         Object data = result.getReceivedExchanges().get(0).getIn().getBody();
 
-        LOG.info(">>> Model generated : " + data.getClass().getName());
+        LOG.info(">>> Model generated : {}", data.getClass().getName());
     }
 
     @Test
diff --git a/components/camel-bindy/src/test/java/org/apache/camel/dataformat/bindy/fix/BindyComplexKeyValuePairStandaloneTest.java b/components/camel-bindy/src/test/java/org/apache/camel/dataformat/bindy/fix/BindyComplexKeyValuePairStandaloneTest.java
index 7efb171fe48..19ee3a89500 100644
--- a/components/camel-bindy/src/test/java/org/apache/camel/dataformat/bindy/fix/BindyComplexKeyValuePairStandaloneTest.java
+++ b/components/camel-bindy/src/test/java/org/apache/camel/dataformat/bindy/fix/BindyComplexKeyValuePairStandaloneTest.java
@@ -83,7 +83,7 @@ public class BindyComplexKeyValuePairStandaloneTest {
         CamelContext camelContext = new DefaultCamelContext();
         factory.bind(camelContext, data, model, counter);
 
-        LOG.info(">>> Model : " + model.toString());
+        LOG.info(">>> Model : {}", model.toString());
 
         assertNotNull(model);
 
@@ -121,7 +121,7 @@ public class BindyComplexKeyValuePairStandaloneTest {
         CamelContext camelContext = new DefaultCamelContext();
         factory.bind(camelContext, data, model, counter);
 
-        LOG.info(">>> Model : " + model.toString());
+        LOG.info(">>> Model : {}", model.toString());
 
         assertNotNull(model);
 
diff --git a/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxCollaborationsManagerIT.java b/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxCollaborationsManagerIT.java
index 104721e7a75..0fee2428c00 100644
--- a/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxCollaborationsManagerIT.java
+++ b/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxCollaborationsManagerIT.java
@@ -74,7 +74,7 @@ public class BoxCollaborationsManagerIT extends AbstractBoxITSupport {
                 testFolder.getID(), headers);
 
         assertNotNull(result, "addFolderCollaboration result");
-        LOG.debug("addFolderCollaboration: " + result);
+        LOG.debug("addFolderCollaboration: {}", result);
     }
 
     @Disabled //creation of app users could be used only with JWT authentication, which is not possible in this time
@@ -100,7 +100,7 @@ public class BoxCollaborationsManagerIT extends AbstractBoxITSupport {
             final com.box.sdk.BoxCollaboration result = requestBodyAndHeaders("direct://ADDFOLDERCOLLABORATION",
                     testFolder.getID(), headers);
             assertNotNull(result, "addFolderCollaboration result");
-            LOG.debug("addFolderCollaboration: " + result);
+            LOG.debug("addFolderCollaboration: {}", result);
         } catch (BoxAPIException e) {
             throw new RuntimeCamelException(
                     String.format("Box API returned the error code %d\n\n%s", e.getResponseCode(), e.getResponse()), e);
@@ -118,7 +118,7 @@ public class BoxCollaborationsManagerIT extends AbstractBoxITSupport {
                 testCollaboration.getID());
 
         assertNotNull(result, "getCollaborationInfo result");
-        LOG.debug("getCollaborationInfo: " + result);
+        LOG.debug("getCollaborationInfo: {}", result);
     }
 
     @Test
@@ -128,7 +128,7 @@ public class BoxCollaborationsManagerIT extends AbstractBoxITSupport {
         final java.util.Collection result = requestBody("direct://GETFOLDERCOLLABORATIONS", testFolder.getID());
 
         assertNotNull(result, "getFolderCollaborations result");
-        LOG.debug("getFolderCollaborations: " + result);
+        LOG.debug("getFolderCollaborations: {}", result);
     }
 
     @SuppressWarnings("rawtypes")
@@ -137,7 +137,7 @@ public class BoxCollaborationsManagerIT extends AbstractBoxITSupport {
         final java.util.Collection result = requestBody("direct://GETPENDINGCOLLABORATIONS", null);
 
         assertNotNull(result, "getPendingCollaborations result");
-        LOG.debug("getPendingCollaborations: " + result);
+        LOG.debug("getPendingCollaborations: {}", result);
     }
 
     @Test
@@ -157,7 +157,7 @@ public class BoxCollaborationsManagerIT extends AbstractBoxITSupport {
         assertNotNull(result, "updateCollaborationInfo result");
         assertNotNull(result.getInfo(), "updateCollaborationInfo info");
         assertEquals(BoxCollaboration.Role.PREVIEWER, result.getInfo().getRole(), "updateCollaborationInfo info");
-        LOG.debug("updateCollaborationInfo: " + result);
+        LOG.debug("updateCollaborationInfo: {}", result);
     }
 
     @Override
diff --git a/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxCommentsManagerIT.java b/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxCommentsManagerIT.java
index ed32c4bad4f..0cd81cefc44 100644
--- a/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxCommentsManagerIT.java
+++ b/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxCommentsManagerIT.java
@@ -69,7 +69,7 @@ public class BoxCommentsManagerIT extends AbstractBoxITSupport {
         assertNotNull(result.getComments(), "addFileComment comments");
         assertTrue(result.getComments().size() > 0, "changeCommentMessage comments size");
         assertEquals(CAMEL_TEST_FILE_COMMENT, result.getComments().get(0).getMessage(), "changeCommentMessage comment message");
-        LOG.debug("addFileComment: " + result);
+        LOG.debug("addFileComment: {}", result);
     }
 
     @Test
@@ -88,7 +88,7 @@ public class BoxCommentsManagerIT extends AbstractBoxITSupport {
         assertNotNull(result, "changeCommentMessage result");
         assertNotNull(result.getInfo().getMessage(), "changeCommentMessage message");
         assertEquals(CAMEL_TEST_FILE_CHANGED_COMMENT, result.getInfo().getMessage(), "changeCommentMessage message");
-        LOG.debug("changeCommentMessage: " + result);
+        LOG.debug("changeCommentMessage: {}", result);
     }
 
     @Test
@@ -113,7 +113,7 @@ public class BoxCommentsManagerIT extends AbstractBoxITSupport {
 
         assertNotNull(result, "getCommentInfo result");
         assertEquals(CAMEL_TEST_FILE_COMMENT, result.getMessage(), "getCommentInfo message");
-        LOG.debug("getCommentInfo: " + result);
+        LOG.debug("getCommentInfo: {}", result);
     }
 
     @Test
@@ -126,7 +126,7 @@ public class BoxCommentsManagerIT extends AbstractBoxITSupport {
 
         assertNotNull(result, "getFileComments result");
         assertEquals(1, result.size(), "getFileComments size");
-        LOG.debug("getFileComments: " + result);
+        LOG.debug("getFileComments: {}", result);
     }
 
     @Test
@@ -144,7 +144,7 @@ public class BoxCommentsManagerIT extends AbstractBoxITSupport {
 
         assertNotNull(result, "replyToComment result");
         assertEquals(CAMEL_TEST_FILE_REPLY_COMMENT, result.getInfo().getMessage(), "replyToComment result");
-        LOG.debug("replyToComment: " + result);
+        LOG.debug("replyToComment: {}", result);
     }
 
     @Override
diff --git a/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxEventLogsManagerIT.java b/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxEventLogsManagerIT.java
index 0b0ffbe6dc7..95832545ae8 100644
--- a/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxEventLogsManagerIT.java
+++ b/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxEventLogsManagerIT.java
@@ -65,7 +65,7 @@ public class BoxEventLogsManagerIT extends AbstractBoxITSupport {
         final java.util.List result = requestBodyAndHeaders("direct://GETENTERPRISEEVENTS", null, headers);
 
         assertNotNull(result, "getEnterpriseEvents result");
-        LOG.debug("getEnterpriseEvents: " + result);
+        LOG.debug("getEnterpriseEvents: {}", result);
     }
 
     @Override
diff --git a/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxEventsManagerIT.java b/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxEventsManagerIT.java
index 84e85e583ce..2d827dd151e 100644
--- a/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxEventsManagerIT.java
+++ b/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxEventsManagerIT.java
@@ -69,7 +69,7 @@ public class BoxEventsManagerIT extends AbstractBoxITSupport {
         final List<Exchange> exchanges = mockEndpoint.getExchanges();
         assertNotNull(exchanges, "poll result");
         assertFalse(exchanges.isEmpty(), "poll result");
-        LOG.debug("poll result: " + exchanges);
+        LOG.debug("poll result: {}", exchanges);
     }
 
     @Override
diff --git a/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxFilesManagerIT.java b/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxFilesManagerIT.java
index 1fcf33ba545..4866cfd4b11 100644
--- a/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxFilesManagerIT.java
+++ b/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxFilesManagerIT.java
@@ -82,7 +82,7 @@ public class BoxFilesManagerIT extends AbstractBoxITSupport {
 
             assertNotNull(result, "copyFile result");
             assertEquals(CAMEL_TEST_COPY_FILE_NAME, result.getInfo().getName(), "copyFile name");
-            LOG.debug("copyFile: " + result);
+            LOG.debug("copyFile: {}", result);
         } finally {
             if (result != null) {
                 result.delete();
@@ -107,7 +107,7 @@ public class BoxFilesManagerIT extends AbstractBoxITSupport {
 
         assertNotNull(result, "createFileMetadata result");
         assertEquals("bar", result.getString("/foo"), "createFileMetadata result");
-        LOG.debug("createFileMetadata: " + result);
+        LOG.debug("createFileMetadata: {}", result);
     }
 
     @Test
@@ -125,7 +125,7 @@ public class BoxFilesManagerIT extends AbstractBoxITSupport {
         final com.box.sdk.BoxSharedLink result = requestBodyAndHeaders("direct://CREATEFILESHAREDLINK", null, headers);
 
         assertNotNull(result, "createFileSharedLink result");
-        LOG.debug("createFileSharedLink: " + result);
+        LOG.debug("createFileSharedLink: {}", result);
     }
 
     @Test
@@ -187,7 +187,7 @@ public class BoxFilesManagerIT extends AbstractBoxITSupport {
         final java.io.OutputStream result = requestBodyAndHeaders("direct://DOWNLOADFILE", null, headers);
 
         assertNotNull(result, "downloadFile result");
-        LOG.debug("downloadFile: " + result);
+        LOG.debug("downloadFile: {}", result);
     }
 
     @Disabled // Requires premium user account to test
@@ -208,7 +208,7 @@ public class BoxFilesManagerIT extends AbstractBoxITSupport {
                 headers);
 
         assertNotNull(result, "downloadPreviousFileVersion result");
-        LOG.debug("downloadPreviousFileVersion: " + result);
+        LOG.debug("downloadPreviousFileVersion: {}", result);
     }
 
     @Test
@@ -217,7 +217,7 @@ public class BoxFilesManagerIT extends AbstractBoxITSupport {
         final java.net.URL result = requestBody("direct://GETDOWNLOADURL", testFile.getID());
 
         assertNotNull(result, "getDownloadURL result");
-        LOG.debug("getDownloadURL: " + result);
+        LOG.debug("getDownloadURL: {}", result);
     }
 
     @Test
@@ -231,7 +231,7 @@ public class BoxFilesManagerIT extends AbstractBoxITSupport {
         final com.box.sdk.BoxFile.Info result = requestBodyAndHeaders("direct://GETFILEINFO", null, headers);
 
         assertNotNull(result, "getFileInfo result");
-        LOG.debug("getFileInfo: " + result);
+        LOG.debug("getFileInfo: {}", result);
     }
 
     @Test
@@ -247,7 +247,7 @@ public class BoxFilesManagerIT extends AbstractBoxITSupport {
         final com.box.sdk.Metadata result = requestBodyAndHeaders("direct://GETFILEMETADATA", null, headers);
 
         assertNotNull(result, "getFileMetadata result");
-        LOG.debug("getFileMetadata: " + result);
+        LOG.debug("getFileMetadata: {}", result);
     }
 
     @Test
@@ -256,7 +256,7 @@ public class BoxFilesManagerIT extends AbstractBoxITSupport {
         final java.net.URL result = requestBody("direct://GETFILEPREVIEWLINK", testFile.getID());
 
         assertNotNull(result, "getFilePreviewLink result");
-        LOG.debug("getFilePreviewLink: " + result);
+        LOG.debug("getFilePreviewLink: {}", result);
     }
 
     @Test
@@ -278,7 +278,7 @@ public class BoxFilesManagerIT extends AbstractBoxITSupport {
         final byte[] result = requestBodyAndHeaders("direct://GETFILETHUMBNAIL", null, headers);
 
         assertNotNull(result, "getFileThumbnail result");
-        LOG.debug("getFileThumbnail: " + result);
+        LOG.debug("getFileThumbnail: {}", result);
     }
 
     @Test
@@ -288,7 +288,7 @@ public class BoxFilesManagerIT extends AbstractBoxITSupport {
         final java.util.Collection result = requestBody("direct://GETFILEVERSIONS", testFile.getID());
 
         assertNotNull(result, "getFileVersions result");
-        LOG.debug("getFileVersions: " + result);
+        LOG.debug("getFileVersions: {}", result);
     }
 
     @Test
@@ -308,7 +308,7 @@ public class BoxFilesManagerIT extends AbstractBoxITSupport {
 
             assertNotNull(result, "moveFile result");
             assertEquals(CAMEL_TEST_MOVE_FILE_NAME, result.getInfo().getName(), "moveFile name");
-            LOG.debug("moveFile: " + result);
+            LOG.debug("moveFile: {}", result);
         } finally {
             if (result != null) {
                 result.delete();
@@ -330,7 +330,7 @@ public class BoxFilesManagerIT extends AbstractBoxITSupport {
         final com.box.sdk.BoxFileVersion result = requestBodyAndHeaders("direct://PROMOTEFILEVERSION", null, headers);
 
         assertNotNull(result, "promoteFileVersion result");
-        LOG.debug("promoteFileVersion: " + result);
+        LOG.debug("promoteFileVersion: {}", result);
     }
 
     @Test
@@ -349,7 +349,7 @@ public class BoxFilesManagerIT extends AbstractBoxITSupport {
 
             assertNotNull(result, "renameFile result");
             assertEquals(CAMEL_TEST_RENAME_FILE_NAME, result.getInfo().getName(), "renameFile name");
-            LOG.debug("renameFile: " + result);
+            LOG.debug("renameFile: {}", result);
         } finally {
             if (result != null) {
                 result.delete();
@@ -372,7 +372,7 @@ public class BoxFilesManagerIT extends AbstractBoxITSupport {
 
         assertNotNull(result, "updateFileInfo result");
         assertEquals(CAMEL_TEST_FILE_DESCRIPTION, result.getInfo().getDescription(), "updateFileInfo info");
-        LOG.debug("updateFileInfo: " + result);
+        LOG.debug("updateFileInfo: {}", result);
     }
 
     @Test
@@ -394,7 +394,7 @@ public class BoxFilesManagerIT extends AbstractBoxITSupport {
         assertNotNull(result, "updateFileMetadata result");
         assertNotNull(result.getString("/foo"), "updateFileMetadata property foo");
         assertEquals("bar", metadata.getString("/foo"));
-        LOG.debug("updateFileMetadata: " + result);
+        LOG.debug("updateFileMetadata: {}", result);
     }
 
     @Test
@@ -414,7 +414,7 @@ public class BoxFilesManagerIT extends AbstractBoxITSupport {
             result = requestBodyAndHeaders("direct://UPLOADFILE", null, headers);
 
             assertNotNull(result, "uploadFile result");
-            LOG.debug("uploadFile: " + result);
+            LOG.debug("uploadFile: {}", result);
         } finally {
             if (result != null) {
                 try {
@@ -443,7 +443,7 @@ public class BoxFilesManagerIT extends AbstractBoxITSupport {
             assertNotNull(result, "uploadFile result");
             result = requestBodyAndHeaders("direct://UPLOADFILEOVERWRITE", null, headers);
             assertNotNull(result, "uploadFile overwrite result");
-            LOG.debug("uploadFile: " + result);
+            LOG.debug("uploadFile: {}", result);
         } finally {
             if (result != null) {
                 try {
@@ -474,7 +474,7 @@ public class BoxFilesManagerIT extends AbstractBoxITSupport {
             result = requestBodyAndHeaders("direct://UPLOADNEWFILEVERSION", null, headers);
 
             assertNotNull(result, "uploadNewFileVersion result");
-            LOG.debug("uploadNewFileVersion: " + result);
+            LOG.debug("uploadNewFileVersion: {}", result);
         } finally {
             if (result != null) {
                 try {
diff --git a/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxFoldersManagerIT.java b/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxFoldersManagerIT.java
index b12801989c1..6576295574e 100644
--- a/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxFoldersManagerIT.java
+++ b/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxFoldersManagerIT.java
@@ -72,7 +72,7 @@ public class BoxFoldersManagerIT extends AbstractBoxITSupport {
 
         assertNotNull(testFolder, "createFolder result");
         assertEquals(CAMEL_TEST_FOLDER, testFolder.getInfo().getName(), "createFolder folder name");
-        LOG.debug("createFolder: " + testFolder);
+        LOG.debug("createFolder: {}", testFolder);
     }
 
     @Test
@@ -91,7 +91,7 @@ public class BoxFoldersManagerIT extends AbstractBoxITSupport {
 
         assertNotNull(testFolder, "createFolder result");
         assertEquals(CAMEL_TEST_FOLDER, testFolder.getInfo().getName(), "createFolder folder name");
-        LOG.debug("createFolder: " + testFolder);
+        LOG.debug("createFolder: {}", testFolder);
     }
 
     @Test
@@ -141,7 +141,7 @@ public class BoxFoldersManagerIT extends AbstractBoxITSupport {
                 headers);
 
         assertNotNull(result, "createFolderSharedLink result");
-        LOG.debug("createFolderSharedLink: " + result);
+        LOG.debug("createFolderSharedLink: {}", result);
     }
 
     @Test
@@ -151,7 +151,7 @@ public class BoxFoldersManagerIT extends AbstractBoxITSupport {
 
         assertNotNull(result, "getFolder result");
         assertEquals(testFolder.getID(), result.getID(), "getFolder folder id");
-        LOG.debug("getFolder: " + result);
+        LOG.debug("getFolder: {}", result);
     }
 
     @Test
@@ -167,7 +167,7 @@ public class BoxFoldersManagerIT extends AbstractBoxITSupport {
         assertNotNull(result, "getFolderInfo result");
         assertNotNull(result.getName(), "getFolderInfo result.getName()");
         assertEquals(CAMEL_TEST_FOLDER, result.getName(), "getFolderInfo info name");
-        LOG.debug("getFolderInfo: " + result);
+        LOG.debug("getFolderInfo: {}", result);
     }
 
     @Test
@@ -186,7 +186,7 @@ public class BoxFoldersManagerIT extends AbstractBoxITSupport {
         final java.util.Collection result = requestBodyAndHeaders("direct://GETFOLDERITEMS", null, headers);
 
         assertNotNull(result, "getFolderItems result");
-        LOG.debug("getFolderItems: " + result);
+        LOG.debug("getFolderItems: {}", result);
     }
 
     @Test
@@ -194,7 +194,7 @@ public class BoxFoldersManagerIT extends AbstractBoxITSupport {
         final com.box.sdk.BoxFolder result = requestBody("direct://GETROOTFOLDER", null);
 
         assertNotNull(result, "getRootFolder result");
-        LOG.debug("getRootFolder: " + result);
+        LOG.debug("getRootFolder: {}", result);
     }
 
     @Test
@@ -211,7 +211,7 @@ public class BoxFoldersManagerIT extends AbstractBoxITSupport {
 
         assertNotNull(result, "moveFolder result");
         assertEquals(CAMEL_TEST_MOVE_FOLDER, result.getInfo().getName(), "moveFolder folder name");
-        LOG.debug("moveFolder: " + result);
+        LOG.debug("moveFolder: {}", result);
     }
 
     @Test
@@ -226,7 +226,7 @@ public class BoxFoldersManagerIT extends AbstractBoxITSupport {
 
         assertNotNull(result, "renameFolder result");
         assertEquals(CAMEL_TEST_RENAME_FOLDER, result.getInfo().getName(), "moveFolder folder name");
-        LOG.debug("renameFolder: " + result);
+        LOG.debug("renameFolder: {}", result);
     }
 
     @Test
@@ -244,7 +244,7 @@ public class BoxFoldersManagerIT extends AbstractBoxITSupport {
 
         assertNotNull(result, "updateInfo result");
         assertEquals(CAMEL_TEST_FOLDER_DESCRIPTION, result.getInfo().getDescription(), "update folder info description");
-        LOG.debug("updateInfo: " + result);
+        LOG.debug("updateInfo: {}", result);
     }
 
     @Override
diff --git a/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxGroupsManagerIT.java b/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxGroupsManagerIT.java
index 6aa0d5d5fcc..a02a459babf 100644
--- a/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxGroupsManagerIT.java
+++ b/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxGroupsManagerIT.java
@@ -70,7 +70,7 @@ public class BoxGroupsManagerIT extends AbstractBoxITSupport {
                 headers);
 
         assertNotNull(result, "addGroupMembership result");
-        LOG.debug("addGroupMembership: " + result);
+        LOG.debug("addGroupMembership: {}", result);
     }
 
     @Test
@@ -82,7 +82,7 @@ public class BoxGroupsManagerIT extends AbstractBoxITSupport {
             result = requestBody("direct://CREATEGROUP", CAMEL_TEST_CREATE_GROUP_NAME);
             assertNotNull(result, "createGroup result");
             assertEquals(CAMEL_TEST_CREATE_GROUP_NAME, result.getInfo().getName());
-            LOG.debug("createGroup: " + result);
+            LOG.debug("createGroup: {}", result);
         } finally {
             if (result != null) {
                 try {
@@ -123,7 +123,7 @@ public class BoxGroupsManagerIT extends AbstractBoxITSupport {
         final java.util.Collection result = requestBody("direct://GETALLGROUPS", null);
 
         assertNotNull(result, "getAllGroups result");
-        LOG.debug("getAllGroups: " + result);
+        LOG.debug("getAllGroups: {}", result);
     }
 
     @Test
@@ -132,7 +132,7 @@ public class BoxGroupsManagerIT extends AbstractBoxITSupport {
         final com.box.sdk.BoxGroup.Info result = requestBody("direct://GETGROUPINFO", testGroup.getID());
 
         assertNotNull(result, "getGroupInfo result");
-        LOG.debug("getGroupInfo: " + result);
+        LOG.debug("getGroupInfo: {}", result);
     }
 
     @Test
@@ -148,7 +148,7 @@ public class BoxGroupsManagerIT extends AbstractBoxITSupport {
             headers.put("CamelBox.groupInfo", info);
             final com.box.sdk.BoxGroup result = requestBodyAndHeaders("direct://UPDATEGROUPINFO", null, headers);
             assertNotNull(result, "updateGroupInfo result");
-            LOG.debug("updateGroupInfo: " + result);
+            LOG.debug("updateGroupInfo: {}", result);
         } finally {
             info = testGroup.getInfo();
             info.setDescription("");
@@ -164,7 +164,7 @@ public class BoxGroupsManagerIT extends AbstractBoxITSupport {
         final com.box.sdk.BoxGroupMembership.Info result = requestBody("direct://GETGROUPMEMBERSHIPINFO", info.getID());
 
         assertNotNull(result, "getGroupMembershipInfo result");
-        LOG.debug("getGroupMembershipInfo: " + result);
+        LOG.debug("getGroupMembershipInfo: {}", result);
     }
 
     @Test
@@ -174,7 +174,7 @@ public class BoxGroupsManagerIT extends AbstractBoxITSupport {
         final java.util.Collection result = requestBody("direct://GETGROUPMEMBERSHIPS", testGroup.getID());
 
         assertNotNull(result, "getGroupMemberships result");
-        LOG.debug("getGroupMemberships: " + result);
+        LOG.debug("getGroupMemberships: {}", result);
     }
 
     @Test
@@ -192,7 +192,7 @@ public class BoxGroupsManagerIT extends AbstractBoxITSupport {
                 headers);
 
         assertNotNull(result, "updateGroupMembershipInfo result");
-        LOG.debug("updateGroupMembershipInfo: " + result);
+        LOG.debug("updateGroupMembershipInfo: {}", result);
     }
 
     @Override
diff --git a/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxSearchManagerIT.java b/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxSearchManagerIT.java
index b082ee50460..01c04aff4b6 100644
--- a/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxSearchManagerIT.java
+++ b/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxSearchManagerIT.java
@@ -61,7 +61,7 @@ public class BoxSearchManagerIT extends AbstractBoxITSupport {
         final java.util.Collection result = requestBodyAndHeaders("direct://SEARCHFOLDER", null, headers);
 
         assertNotNull(result, "searchFolder result");
-        LOG.debug("searchFolder: " + result);
+        LOG.debug("searchFolder: {}", result);
     }
 
     @Override
diff --git a/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxTasksManagerIT.java b/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxTasksManagerIT.java
index e4f90755c71..e31c202ff0a 100644
--- a/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxTasksManagerIT.java
+++ b/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxTasksManagerIT.java
@@ -75,7 +75,7 @@ public class BoxTasksManagerIT extends AbstractBoxITSupport {
         result = requestBodyAndHeaders("direct://ADDASSIGNMENTTOTASK", null, headers);
 
         assertNotNull(result, "addAssignmentToTask result");
-        LOG.debug("addAssignmentToTask: " + result);
+        LOG.debug("addAssignmentToTask: {}", result);
     }
 
     @Test
@@ -98,7 +98,7 @@ public class BoxTasksManagerIT extends AbstractBoxITSupport {
             result = requestBodyAndHeaders("direct://ADDFILETASK", null, headers);
 
             assertNotNull(result, "addFileTask result");
-            LOG.debug("addFileTask: " + result);
+            LOG.debug("addFileTask: {}", result);
         } finally {
             if (result != null) {
                 try {
@@ -137,7 +137,7 @@ public class BoxTasksManagerIT extends AbstractBoxITSupport {
         final java.util.List result = requestBody("direct://GETFILETASKS", testFile.getID());
 
         assertNotNull(result, "getFileTasks result");
-        LOG.debug("getFileTasks: " + result);
+        LOG.debug("getFileTasks: {}", result);
     }
 
     @Disabled
@@ -151,7 +151,7 @@ public class BoxTasksManagerIT extends AbstractBoxITSupport {
             result = requestBody("direct://GETTASKASSIGNMENTINFO", info.getID());
 
             assertNotNull(result, "getTaskAssignmentInfo result");
-            LOG.debug("getTaskAssignmentInfo: " + result);
+            LOG.debug("getTaskAssignmentInfo: {}", result);
         } finally {
             if (result != null) {
                 try {
@@ -181,7 +181,7 @@ public class BoxTasksManagerIT extends AbstractBoxITSupport {
         final java.util.List result = requestBody("direct://GETTASKASSIGNMENTS", testTask.getID());
 
         assertNotNull(result, "getTaskAssignments result");
-        LOG.debug("getTaskAssignments: " + result);
+        LOG.debug("getTaskAssignments: {}", result);
     }
 
     @Test
@@ -190,7 +190,7 @@ public class BoxTasksManagerIT extends AbstractBoxITSupport {
         final com.box.sdk.BoxTask.Info result = requestBody("direct://GETTASKINFO", testTask.getID());
 
         assertNotNull(result, "getTaskInfo result");
-        LOG.debug("getTaskInfo: " + result);
+        LOG.debug("getTaskInfo: {}", result);
     }
 
     @Disabled // No way to change BoxTask.Info parameters
@@ -207,7 +207,7 @@ public class BoxTasksManagerIT extends AbstractBoxITSupport {
         final com.box.sdk.BoxTask result = requestBodyAndHeaders("direct://UPDATETASKINFO", null, headers);
 
         assertNotNull(result, "updateTaskInfo result");
-        LOG.debug("updateTaskInfo: " + result);
+        LOG.debug("updateTaskInfo: {}", result);
     }
 
     @Override
diff --git a/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxUsersManagerIT.java b/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxUsersManagerIT.java
index e03a2d9acd9..d431c70567f 100644
--- a/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxUsersManagerIT.java
+++ b/components/camel-box/camel-box-component/src/test/java/org/apache/camel/component/box/BoxUsersManagerIT.java
@@ -76,7 +76,7 @@ public class BoxUsersManagerIT extends AbstractBoxITSupport {
             headers.put("CamelBox.email", CAMEL_TEST_USER_EMAIL_ALIAS);
             result = requestBodyAndHeaders("direct://ADDUSEREMAILALIAS", null, headers);
             assertNotNull(result, "addUserEmailAlias result");
-            LOG.debug("addUserEmailAlias: " + result);
+            LOG.debug("addUserEmailAlias: {}", result);
         } finally {
             if (result != null) {
                 try {
@@ -107,7 +107,7 @@ public class BoxUsersManagerIT extends AbstractBoxITSupport {
             result = requestBodyAndHeaders("direct://CREATEAPPUSER", null, headers);
 
             assertNotNull(result, "createAppUser result");
-            LOG.debug("createAppUser: " + result);
+            LOG.debug("createAppUser: {}", result);
         } finally {
             if (result != null) {
                 try {
@@ -148,7 +148,7 @@ public class BoxUsersManagerIT extends AbstractBoxITSupport {
             result = requestBodyAndHeaders("direct://CREATEENTERPRISEUSER", null, headers);
 
             assertNotNull(result, "createEnterpriseUser result");
-            LOG.debug("createEnterpriseUser: " + result);
+            LOG.debug("createEnterpriseUser: {}", result);
         } finally {
             if (result != null) {
                 try {
@@ -216,7 +216,7 @@ public class BoxUsersManagerIT extends AbstractBoxITSupport {
         final java.util.List result = requestBodyAndHeaders("direct://GETALLENTERPRISEOREXTERNALUSERS", null, headers);
 
         assertNotNull(result, "getAllEnterpriseOrExternalUsers result");
-        LOG.debug("getAllEnterpriseOrExternalUsers: " + result);
+        LOG.debug("getAllEnterpriseOrExternalUsers: {}", result);
     }
 
     @Test
@@ -224,7 +224,7 @@ public class BoxUsersManagerIT extends AbstractBoxITSupport {
         final com.box.sdk.BoxUser result = requestBody("direct://GETCURRENTUSER", testUser.getID());
 
         assertNotNull(result, "getCurrentUser result");
-        LOG.debug("getCurrentUser: " + result);
+        LOG.debug("getCurrentUser: {}", result);
     }
 
     @Test
@@ -234,7 +234,7 @@ public class BoxUsersManagerIT extends AbstractBoxITSupport {
         final java.util.Collection result = requestBody("direct://GETUSEREMAILALIAS", testUser.getID());
 
         assertNotNull(result, "getUserEmailAlias result");
-        LOG.debug("getUserEmailAlias: " + result);
+        LOG.debug("getUserEmailAlias: {}", result);
     }
 
     @Test
@@ -243,7 +243,7 @@ public class BoxUsersManagerIT extends AbstractBoxITSupport {
         final com.box.sdk.BoxUser.Info result = requestBody("direct://GETUSERINFO", testUser.getID());
 
         assertNotNull(result, "getUserInfo result");
-        LOG.debug("getUserInfo: " + result);
+        LOG.debug("getUserInfo: {}", result);
     }
 
     @Test
@@ -262,7 +262,7 @@ public class BoxUsersManagerIT extends AbstractBoxITSupport {
             headers.put("CamelBox.info", info);
             final com.box.sdk.BoxUser result = requestBodyAndHeaders("direct://UPDATEUSERINFO", null, headers);
             assertNotNull(result, "updateUserInfo result");
-            LOG.debug("updateUserInfo: " + result);
+            LOG.debug("updateUserInfo: {}", result);
         } finally {
             info = testUser.getInfo();
             info.setJobTitle("");
diff --git a/components/camel-braintree/src/test/java/org/apache/camel/component/braintree/AddOnGatewayIT.java b/components/camel-braintree/src/test/java/org/apache/camel/component/braintree/AddOnGatewayIT.java
index 11f5f087b11..ecd753c7294 100644
--- a/components/camel-braintree/src/test/java/org/apache/camel/component/braintree/AddOnGatewayIT.java
+++ b/components/camel-braintree/src/test/java/org/apache/camel/component/braintree/AddOnGatewayIT.java
@@ -41,7 +41,7 @@ public class AddOnGatewayIT extends AbstractBraintreeTestSupport {
         final List<AddOn> result = requestBody("direct://ALL", null, List.class);
 
         assertNotNull(result, "all result");
-        LOG.debug("all: " + result);
+        LOG.debug("all: {}", result);
     }
 
     @Override
diff --git a/components/camel-braintree/src/test/java/org/apache/camel/component/braintree/CreditCardVerificationGatewayIT.java b/components/camel-braintree/src/test/java/org/apache/camel/component/braintree/CreditCardVerificationGatewayIT.java
index dbf07ed1299..53428832c16 100644
--- a/components/camel-braintree/src/test/java/org/apache/camel/component/braintree/CreditCardVerificationGatewayIT.java
+++ b/components/camel-braintree/src/test/java/org/apache/camel/component/braintree/CreditCardVerificationGatewayIT.java
@@ -44,7 +44,7 @@ public class CreditCardVerificationGatewayIT extends AbstractBraintreeTestSuppor
         final CreditCardVerification result = requestBody("direct://FIND", null, CreditCardVerification.class);
 
         assertNotNull(result, "find result");
-        LOG.debug("find: " + result);
+        LOG.debug("find: {}", result);
     }
 
     // TODO provide parameter values for search
@@ -56,7 +56,7 @@ public class CreditCardVerificationGatewayIT extends AbstractBraintreeTestSuppor
                 = requestBody("direct://SEARCH", null, ResourceCollection.class);
 
         assertNotNull(result, "search result");
-        LOG.debug("search: " + result);
+        LOG.debug("search: {}", result);
     }
 
     @Override
diff --git a/components/camel-braintree/src/test/java/org/apache/camel/component/braintree/DiscountGatewayIT.java b/components/camel-braintree/src/test/java/org/apache/camel/component/braintree/DiscountGatewayIT.java
index 70cfb31a911..6766bd18fd0 100644
--- a/components/camel-braintree/src/test/java/org/apache/camel/component/braintree/DiscountGatewayIT.java
+++ b/components/camel-braintree/src/test/java/org/apache/camel/component/braintree/DiscountGatewayIT.java
@@ -43,7 +43,7 @@ public class DiscountGatewayIT extends AbstractBraintreeTestSupport {
         final List<Discount> result = requestBody("direct://ALL", null, List.class);
 
         assertNotNull(result, "all result");
-        LOG.debug("all: " + result);
+        LOG.debug("all: {}", result);
     }
 
     @Override
diff --git a/components/camel-braintree/src/test/java/org/apache/camel/component/braintree/PaymentMethodNonceGatewayIT.java b/components/camel-braintree/src/test/java/org/apache/camel/component/braintree/PaymentMethodNonceGatewayIT.java
index fa93bc5ba08..51c9f7f0ce7 100644
--- a/components/camel-braintree/src/test/java/org/apache/camel/component/braintree/PaymentMethodNonceGatewayIT.java
+++ b/components/camel-braintree/src/test/java/org/apache/camel/component/braintree/PaymentMethodNonceGatewayIT.java
@@ -42,7 +42,7 @@ public class PaymentMethodNonceGatewayIT extends AbstractBraintreeTestSupport {
         final com.braintreegateway.Result result = requestBody("direct://CREATE", null);
 
         assertNotNull(result, "create result");
-        LOG.debug("create: " + result);
+        LOG.debug("create: {}", result);
     }
 
     // TODO provide parameter values for find
@@ -53,7 +53,7 @@ public class PaymentMethodNonceGatewayIT extends AbstractBraintreeTestSupport {
         final com.braintreegateway.PaymentMethodNonce result = requestBody("direct://FIND", null);
 
         assertNotNull(result, "find result");
-        LOG.debug("find: " + result);
+        LOG.debug("find: {}", result);
     }
 
     @Override
diff --git a/components/camel-braintree/src/test/java/org/apache/camel/component/braintree/PlanGatewayIT.java b/components/camel-braintree/src/test/java/org/apache/camel/component/braintree/PlanGatewayIT.java
index 21dbd79c6d0..32d8650eddc 100644
--- a/components/camel-braintree/src/test/java/org/apache/camel/component/braintree/PlanGatewayIT.java
+++ b/components/camel-braintree/src/test/java/org/apache/camel/component/braintree/PlanGatewayIT.java
@@ -41,7 +41,7 @@ public class PlanGatewayIT extends AbstractBraintreeTestSupport {
         final List<Plan> result = requestBody("direct://ALL", null, List.class);
 
         assertNotNull(result, "all result");
-        LOG.debug("all: " + result);
+        LOG.debug("all: {}", result);
     }
 
     @Override
diff --git a/components/camel-braintree/src/test/java/org/apache/camel/component/braintree/ReportGatewayIT.java b/components/camel-braintree/src/test/java/org/apache/camel/component/braintree/ReportGatewayIT.java
index 0dd85775a92..8f416993dbe 100644
--- a/components/camel-braintree/src/test/java/org/apache/camel/component/braintree/ReportGatewayIT.java
+++ b/components/camel-braintree/src/test/java/org/apache/camel/component/braintree/ReportGatewayIT.java
@@ -71,7 +71,7 @@ public class ReportGatewayIT extends AbstractBraintreeTestSupport {
         TransactionLevelFeeReport report = result.getTarget();
         assertNotNull(report);
 
-        LOG.debug("transactionLevelFees: " + result);
+        LOG.debug("transactionLevelFees: {}", result);
     }
 
     @Override
diff --git a/components/camel-braintree/src/test/java/org/apache/camel/component/braintree/SettlementBatchSummaryGatewayIT.java b/components/camel-braintree/src/test/java/org/apache/camel/component/braintree/SettlementBatchSummaryGatewayIT.java
index fa9adb8d8dd..8f85f970916 100644
--- a/components/camel-braintree/src/test/java/org/apache/camel/component/braintree/SettlementBatchSummaryGatewayIT.java
+++ b/components/camel-braintree/src/test/java/org/apache/camel/component/braintree/SettlementBatchSummaryGatewayIT.java
@@ -45,7 +45,7 @@ public class SettlementBatchSummaryGatewayIT extends AbstractBraintreeTestSuppor
         final com.braintreegateway.Result result = requestBody("direct://GENERATE", null);
 
         assertNotNull(result, "generate result");
-        LOG.debug("generate: " + result);
+        LOG.debug("generate: {}", result);
     }
 
     // TODO provide parameter values for generate
@@ -61,7 +61,7 @@ public class SettlementBatchSummaryGatewayIT extends AbstractBraintreeTestSuppor
         final com.braintreegateway.Result result = requestBodyAndHeaders("direct://GENERATE_1", null, headers);
 
         assertNotNull(result, "generate result");
-        LOG.debug("generate: " + result);
+        LOG.debug("generate: {}", result);
     }
 
     @Override
diff --git a/components/camel-braintree/src/test/java/org/apache/camel/component/braintree/SubscriptionGatewayIT.java b/components/camel-braintree/src/test/java/org/apache/camel/component/braintree/SubscriptionGatewayIT.java
index bc0bd0f9078..b2fa998fc6c 100644
--- a/components/camel-braintree/src/test/java/org/apache/camel/component/braintree/SubscriptionGatewayIT.java
+++ b/components/camel-braintree/src/test/java/org/apache/camel/component/braintree/SubscriptionGatewayIT.java
@@ -45,7 +45,7 @@ public class SubscriptionGatewayIT extends AbstractBraintreeTestSupport {
         final com.braintreegateway.Result result = requestBody("direct://CANCEL", null);
 
         assertNotNull(result, "cancel result");
-        LOG.debug("cancel: " + result);
+        LOG.debug("cancel: {}", result);
     }
 
     // TODO provide parameter values for create
@@ -56,7 +56,7 @@ public class SubscriptionGatewayIT extends AbstractBraintreeTestSupport {
         final com.braintreegateway.Result result = requestBody("direct://CREATE", null);
 
         assertNotNull(result, "create result");
-        LOG.debug("create: " + result);
+        LOG.debug("create: {}", result);
     }
 
     // TODO provide parameter values for delete
@@ -72,7 +72,7 @@ public class SubscriptionGatewayIT extends AbstractBraintreeTestSupport {
         final com.braintreegateway.Result result = requestBodyAndHeaders("direct://DELETE", null, headers);
 
         assertNotNull(result, "delete result");
-        LOG.debug("delete: " + result);
+        LOG.debug("delete: {}", result);
     }
 
     // TODO provide parameter values for find
@@ -83,7 +83,7 @@ public class SubscriptionGatewayIT extends AbstractBraintreeTestSupport {
         final com.braintreegateway.Subscription result = requestBody("direct://FIND", null);
 
         assertNotNull(result, "find result");
-        LOG.debug("find: " + result);
+        LOG.debug("find: {}", result);
     }
 
     // TODO provide parameter values for retryCharge
@@ -94,7 +94,7 @@ public class SubscriptionGatewayIT extends AbstractBraintreeTestSupport {
         final com.braintreegateway.Result result = requestBody("direct://RETRYCHARGE", null);
 
         assertNotNull(result, "retryCharge result");
-        LOG.debug("retryCharge: " + result);
+        LOG.debug("retryCharge: {}", result);
     }
 
     // TODO provide parameter values for retryCharge
@@ -110,7 +110,7 @@ public class SubscriptionGatewayIT extends AbstractBraintreeTestSupport {
         final com.braintreegateway.Result result = requestBodyAndHeaders("direct://RETRYCHARGE_1", null, headers);
 
         assertNotNull(result, "retryCharge result");
-        LOG.debug("retryCharge: " + result);
+        LOG.debug("retryCharge: {}", result);
     }
 
     // TODO provide parameter values for search
@@ -121,7 +121,7 @@ public class SubscriptionGatewayIT extends AbstractBraintreeTestSupport {
         final com.braintreegateway.ResourceCollection result = requestBody("direct://SEARCH", null);
 
         assertNotNull(result, "search result");
-        LOG.debug("search: " + result);
+        LOG.debug("search: {}", result);
     }
 
     // TODO provide parameter values for update
@@ -137,7 +137,7 @@ public class SubscriptionGatewayIT extends AbstractBraintreeTestSupport {
         final com.braintreegateway.Result result = requestBodyAndHeaders("direct://UPDATE", null, headers);
 
         assertNotNull(result, "update result");
-        LOG.debug("update: " + result);
+        LOG.debug("update: {}", result);
     }
 
     @Override
diff --git a/components/camel-braintree/src/test/java/org/apache/camel/component/braintree/TransactionGatewayIT.java b/components/camel-braintree/src/test/java/org/apache/camel/component/braintree/TransactionGatewayIT.java
index 6203ee3c452..afef825b85b 100644
--- a/components/camel-braintree/src/test/java/org/apache/camel/component/braintree/TransactionGatewayIT.java
+++ b/components/camel-braintree/src/test/java/org/apache/camel/component/braintree/TransactionGatewayIT.java
@@ -395,7 +395,7 @@ public class TransactionGatewayIT extends AbstractBraintreeTestSupport {
         final com.braintreegateway.Result result = requestBody("direct://CANCELRELEASE", null);
 
         assertNotNull(result, "cancelRelease result");
-        LOG.debug("cancelRelease: " + result);
+        LOG.debug("cancelRelease: {}", result);
     }
 
     // TODO provide parameter values for credit
@@ -406,7 +406,7 @@ public class TransactionGatewayIT extends AbstractBraintreeTestSupport {
         final com.braintreegateway.Result result = requestBody("direct://CREDIT", null);
 
         assertNotNull(result, "credit result");
-        LOG.debug("credit: " + result);
+        LOG.debug("credit: {}", result);
     }
 
     // TODO provide parameter values for holdInEscrow
@@ -417,7 +417,7 @@ public class TransactionGatewayIT extends AbstractBraintreeTestSupport {
         final com.braintreegateway.Result result = requestBody("direct://HOLDINESCROW", null);
 
         assertNotNull(result, "holdInEscrow result");
-        LOG.debug("holdInEscrow: " + result);
+        LOG.debug("holdInEscrow: {}", result);
     }
 
     // TODO provide parameter values for releaseFromEscrow
@@ -428,7 +428,7 @@ public class TransactionGatewayIT extends AbstractBraintreeTestSupport {
         final com.braintreegateway.Result result = requestBody("direct://RELEASEFROMESCROW", null);
 
         assertNotNull(result, "releaseFromEscrow result");
-        LOG.debug("releaseFromEscrow: " + result);
+        LOG.debug("releaseFromEscrow: {}", result);
     }
 
     // TODO provide parameter values for search
@@ -439,7 +439,7 @@ public class TransactionGatewayIT extends AbstractBraintreeTestSupport {
         final com.braintreegateway.ResourceCollection result = requestBody("direct://SEARCH", null);
 
         assertNotNull(result, "search result");
-        LOG.debug("search: " + result);
+        LOG.debug("search: {}", result);
     }
 
     // TODO provide parameter values for submitForPartialSettlement
@@ -455,7 +455,7 @@ public class TransactionGatewayIT extends AbstractBraintreeTestSupport {
         final com.braintreegateway.Result result = requestBodyAndHeaders("direct://SUBMITFORPARTIALSETTLEMENT", null, headers);
 
         assertNotNull(result, "submitForPartialSettlement result");
-        LOG.debug("submitForPartialSettlement: " + result);
+        LOG.debug("submitForPartialSettlement: {}", result);
     }
 
     // TODO provide parameter values for voidTransaction
@@ -466,7 +466,7 @@ public class TransactionGatewayIT extends AbstractBraintreeTestSupport {
         final com.braintreegateway.Result result = requestBody("direct://VOIDTRANSACTION", null);
 
         assertNotNull(result, "voidTransaction result");
-        LOG.debug("voidTransaction: " + result);
+        LOG.debug("voidTransaction: {}", result);
     }
 
     // *************************************************************************
diff --git a/components/camel-crypto/src/test/java/org/apache/camel/component/crypto/ECDSASignatureTest.java b/components/camel-crypto/src/test/java/org/apache/camel/component/crypto/ECDSASignatureTest.java
index 3ddc42949cb..208a889079d 100644
--- a/components/camel-crypto/src/test/java/org/apache/camel/component/crypto/ECDSASignatureTest.java
+++ b/components/camel-crypto/src/test/java/org/apache/camel/component/crypto/ECDSASignatureTest.java
@@ -63,7 +63,7 @@ public class ECDSASignatureTest extends CamelTestSupport {
             privateKey = (PrivateKey) keyStore.getKey("ECDSA", "security".toCharArray());
             x509 = (X509Certificate) keyStore.getCertificate("ECDSA");
         } catch (Throwable e) {
-            LOG.warn("Cannot setup keystore for running this test due " + e.getMessage() + ". This test is skipped.", e);
+            LOG.warn("Cannot setup keystore for running this test due {}. This test is skipped.", e.getMessage(), e);
             canRun = false;
         }
     }
diff --git a/components/camel-csv/src/test/java/org/apache/camel/dataformat/csv/CsvRouteTest.java b/components/camel-csv/src/test/java/org/apache/camel/dataformat/csv/CsvRouteTest.java
index 9d85169587f..2d38b4d1bf7 100644
--- a/components/camel-csv/src/test/java/org/apache/camel/dataformat/csv/CsvRouteTest.java
+++ b/components/camel-csv/src/test/java/org/apache/camel/dataformat/csv/CsvRouteTest.java
@@ -55,7 +55,7 @@ public class CsvRouteTest extends CamelTestSupport {
             Message in = exchange.getIn();
             String text = in.getBody(String.class);
 
-            LOG.debug("Received " + text);
+            LOG.debug("Received {}", text);
             assertNotNull(text, "Should be able to convert received body to a string");
 
             // order is not guaranteed with a Map (which was passed in before)
@@ -92,7 +92,7 @@ public class CsvRouteTest extends CamelTestSupport {
         Message in2 = list.get(1).getIn();
         String text2 = in2.getBody(String.class);
 
-        LOG.debug("Received " + text2);
+        LOG.debug("Received {}", text2);
 
         // fields should keep the same order from one call to the other
         if (text1.trim().equals("abc,123")) {
@@ -130,7 +130,7 @@ public class CsvRouteTest extends CamelTestSupport {
         Message in2 = list.get(1).getIn();
         String text2 = in2.getBody(String.class);
 
-        LOG.debug("Received " + text2);
+        LOG.debug("Received {}", text2);
         assertEquals("def;789;456", text2.trim(), "Second CSV body has wrong value");
 
     }
diff --git a/components/camel-datasonnet/src/main/java/org/apache/camel/language/datasonnet/DatasonnetExpression.java b/components/camel-datasonnet/src/main/java/org/apache/camel/language/datasonnet/DatasonnetExpression.java
index 58c18e2197e..1071a82756b 100644
--- a/components/camel-datasonnet/src/main/java/org/apache/camel/language/datasonnet/DatasonnetExpression.java
+++ b/components/camel-datasonnet/src/main/java/org/apache/camel/language/datasonnet/DatasonnetExpression.java
@@ -176,7 +176,7 @@ public class DatasonnetExpression extends ExpressionAdapter implements Expressio
                         }
                     });
                 } catch (IOException e) {
-                    LOG.warn("Unable to load DataSonnet library from: " + nextPath, e);
+                    LOG.warn("Unable to load DataSonnet library from: {}", nextPath, e);
                 }
             }
         }
diff --git a/components/camel-debezium/camel-debezium-db2/src/main/docs/debezium-db2-component.adoc b/components/camel-debezium/camel-debezium-db2/src/main/docs/debezium-db2-component.adoc
index 478bdaa74fb..dcaeb2bc244 100644
--- a/components/camel-debezium/camel-debezium-db2/src/main/docs/debezium-db2-component.adoc
+++ b/components/camel-debezium/camel-debezium-db2/src/main/docs/debezium-db2-component.adoc
@@ -99,10 +99,10 @@ from("debezium-db2:[name]?[options]])
         final Struct bodyValue = exchange.getIn().getBody(Struct.class);
         final Schema schemaValue = bodyValue.schema();
 
-        log.info("Body value is :" + bodyValue);
-        log.info("With Schema : " + schemaValue);
-        log.info("And fields of :" + schemaValue.fields());
-        log.info("Field name has `" + schemaValue.field("name").schema() + "` type");
+        log.info("Body value is : {}", bodyValue);
+        log.info("With Schema : {}", schemaValue);
+        log.info("And fields of : {}", schemaValue.fields());
+        log.info("Field name has `{}` type", schemaValue.field("name").schema());
     });
 ----
 
diff --git a/components/camel-debezium/camel-debezium-mysql/src/main/docs/debezium-mysql-component.adoc b/components/camel-debezium/camel-debezium-mysql/src/main/docs/debezium-mysql-component.adoc
index 8723d5c5690..c92d8e820cf 100644
--- a/components/camel-debezium/camel-debezium-mysql/src/main/docs/debezium-mysql-component.adoc
+++ b/components/camel-debezium/camel-debezium-mysql/src/main/docs/debezium-mysql-component.adoc
@@ -108,10 +108,10 @@ from("debezium-mysql:[name]?[options]])
         final Struct bodyValue = exchange.getIn().getBody(Struct.class);
         final Schema schemaValue = bodyValue.schema();
 
-        log.info("Body value is :" + bodyValue);
-        log.info("With Schema : " + schemaValue);
-        log.info("And fields of :" + schemaValue.fields());
-        log.info("Field name has `" + schemaValue.field("name").schema() + "` type");
+        log.info("Body value is : {}", bodyValue);
+        log.info("With Schema : {}", schemaValue);
+        log.info("And fields of : {}", schemaValue.fields());
+        log.info("Field name has `{}` type", schemaValue.field("name").schema());
     });
 ----
 
diff --git a/components/camel-debezium/camel-debezium-oracle/src/main/docs/debezium-oracle-component.adoc b/components/camel-debezium/camel-debezium-oracle/src/main/docs/debezium-oracle-component.adoc
index 3ab55cda469..d29033985f2 100644
--- a/components/camel-debezium/camel-debezium-oracle/src/main/docs/debezium-oracle-component.adoc
+++ b/components/camel-debezium/camel-debezium-oracle/src/main/docs/debezium-oracle-component.adoc
@@ -99,10 +99,10 @@ from("debezium-oracle:[name]?[options]])
         final Struct bodyValue = exchange.getIn().getBody(Struct.class);
         final Schema schemaValue = bodyValue.schema();
 
-        log.info("Body value is :" + bodyValue);
-        log.info("With Schema : " + schemaValue);
-        log.info("And fields of :" + schemaValue.fields());
-        log.info("Field name has `" + schemaValue.field("name").schema() + "` type");
+        log.info("Body value is : {}", bodyValue);
+        log.info("With Schema : {}", schemaValue);
+        log.info("And fields of : {}", schemaValue.fields());
+        log.info("Field name has `{}` type", schemaValue.field("name").schema());
     });
 ----
 
diff --git a/components/camel-debezium/camel-debezium-postgres/src/main/docs/debezium-postgres-component.adoc b/components/camel-debezium/camel-debezium-postgres/src/main/docs/debezium-postgres-component.adoc
index 911ce0c6698..ea17ef2781f 100644
--- a/components/camel-debezium/camel-debezium-postgres/src/main/docs/debezium-postgres-component.adoc
+++ b/components/camel-debezium/camel-debezium-postgres/src/main/docs/debezium-postgres-component.adoc
@@ -99,10 +99,10 @@ from("debezium-postgres:[name]?[options]])
         final Struct bodyValue = exchange.getIn().getBody(Struct.class);
         final Schema schemaValue = bodyValue.schema();
 
-        log.info("Body value is :" + bodyValue);
-        log.info("With Schema : " + schemaValue);
-        log.info("And fields of :" + schemaValue.fields());
-        log.info("Field name has `" + schemaValue.field("name").schema() + "` type");
+        log.info("Body value is : {}", bodyValue);
+        log.info("With Schema : {}", schemaValue);
+        log.info("And fields of : {}", schemaValue.fields());
+        log.info("Field name has `{}` type", schemaValue.field("name").schema());
     });
 ----
 
diff --git a/components/camel-debezium/camel-debezium-sqlserver/src/main/docs/debezium-sqlserver-component.adoc b/components/camel-debezium/camel-debezium-sqlserver/src/main/docs/debezium-sqlserver-component.adoc
index d00243cfd41..45adfe6973e 100644
--- a/components/camel-debezium/camel-debezium-sqlserver/src/main/docs/debezium-sqlserver-component.adoc
+++ b/components/camel-debezium/camel-debezium-sqlserver/src/main/docs/debezium-sqlserver-component.adoc
@@ -97,10 +97,10 @@ from("debezium-sqlserver:[name]?[options]])
         final Struct bodyValue = exchange.getIn().getBody(Struct.class);
         final Schema schemaValue = bodyValue.schema();
 
-        log.info("Body value is :" + bodyValue);
-        log.info("With Schema : " + schemaValue);
-        log.info("And fields of :" + schemaValue.fields());
-        log.info("Field name has `" + schemaValue.field("name").schema() + "` type");
+        log.info("Body value is : {}", bodyValue);
+        log.info("With Schema : {}", schemaValue);
+        log.info("And fields of : {}", schemaValue.fields());
+        log.info("Field name has `{}` type", schemaValue.field("name").schema());
     });
 ----
 
diff --git a/components/camel-debug/src/main/java/org/apache/camel/component/debug/JmxConnectorService.java b/components/camel-debug/src/main/java/org/apache/camel/component/debug/JmxConnectorService.java
index 2d2cb7a9b6e..d0c75f85561 100644
--- a/components/camel-debug/src/main/java/org/apache/camel/component/debug/JmxConnectorService.java
+++ b/components/camel-debug/src/main/java/org/apache/camel/component/debug/JmxConnectorService.java
@@ -139,7 +139,7 @@ public class JmxConnectorService extends ServiceSupport implements CamelContextA
                 cs.start();
                 LOG.info("JMX Connector thread started and listening at: {}", url);
             } catch (IOException ioe) {
-                LOG.warn("Could not start JMXConnector thread at: " + url + ". JMX Connector not in use.", ioe);
+                LOG.warn("Could not start JMXConnector thread at: {}. JMX Connector not in use.", url, ioe);
             }
         });
         thread.start();
diff --git a/components/camel-disruptor/src/test/java/org/apache/camel/component/disruptor/DirectRequestReplyAndDisruptorInOnlyTest.java b/components/camel-disruptor/src/test/java/org/apache/camel/component/disruptor/DirectRequestReplyAndDisruptorInOnlyTest.java
index eaf3ef15f1d..dbf41f2ba48 100644
--- a/components/camel-disruptor/src/test/java/org/apache/camel/component/disruptor/DirectRequestReplyAndDisruptorInOnlyTest.java
+++ b/components/camel-disruptor/src/test/java/org/apache/camel/component/disruptor/DirectRequestReplyAndDisruptorInOnlyTest.java
@@ -36,7 +36,7 @@ public class DirectRequestReplyAndDisruptorInOnlyTest extends CamelTestSupport {
 
         final String out = template.requestBody("direct:start", "Hello World", String.class);
         assertEquals("Bye World", out);
-        LOG.info("Got reply " + out);
+        LOG.info("Got reply {}", out);
 
         MockEndpoint.assertIsSatisfied(context);
     }
diff --git a/components/camel-disruptor/src/test/java/org/apache/camel/component/disruptor/DisruptorRouteTest.java b/components/camel-disruptor/src/test/java/org/apache/camel/component/disruptor/DisruptorRouteTest.java
index a160ef1553e..de085d2cdf0 100644
--- a/components/camel-disruptor/src/test/java/org/apache/camel/component/disruptor/DisruptorRouteTest.java
+++ b/components/camel-disruptor/src/test/java/org/apache/camel/component/disruptor/DisruptorRouteTest.java
@@ -45,7 +45,7 @@ public class DisruptorRouteTest {
                 from("disruptor:test.b").process(new Processor() {
                     @Override
                     public void process(final Exchange e) {
-                        log.debug("Received exchange: " + e.getIn());
+                        log.debug("Received exchange: {}", e.getIn());
                         latch.countDown();
                     }
                 });
@@ -82,7 +82,7 @@ public class DisruptorRouteTest {
                 from("disruptor:test.b").process(new Processor() {
                     @Override
                     public void process(final Exchange e) {
-                        log.debug("Received exchange: " + e.getIn());
+                        log.debug("Received exchange: {}", e.getIn());
                         latch.countDown();
                     }
                 });
diff --git a/components/camel-exec/src/test/java/org/apache/camel/component/exec/ExecTestUtils.java b/components/camel-exec/src/test/java/org/apache/camel/component/exec/ExecTestUtils.java
index 1ec4d8a7d22..b7e6d184400 100644
--- a/components/camel-exec/src/test/java/org/apache/camel/component/exec/ExecTestUtils.java
+++ b/components/camel-exec/src/test/java/org/apache/camel/component/exec/ExecTestUtils.java
@@ -47,7 +47,7 @@ public final class ExecTestUtils {
             File resourceFile = resource.getFile();
             return resourceFile;
         } catch (IOException ioe) {
-            LOG.warn("The resource  " + classpathResource + " does not exist!", ioe);
+            LOG.warn("The resource  {} does not exist!", classpathResource, ioe);
             return null;
         }
     }
diff --git a/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirCapabilitiesIT.java b/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirCapabilitiesIT.java
index cb0720beca9..f19031c47b7 100644
--- a/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirCapabilitiesIT.java
+++ b/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirCapabilitiesIT.java
@@ -49,7 +49,7 @@ public class FhirCapabilitiesIT extends AbstractFhirTestSupport {
     public void testOfType() {
         org.hl7.fhir.instance.model.api.IBaseConformance result = requestBody("direct://OF_TYPE", CapabilityStatement.class);
 
-        LOG.debug("ofType: " + result);
+        LOG.debug("ofType: {}", result);
         assertNotNull(result, "ofType result");
         assertEquals(Enumerations.PublicationStatus.ACTIVE, ((CapabilityStatement) result).getStatus());
     }
@@ -62,7 +62,7 @@ public class FhirCapabilitiesIT extends AbstractFhirTestSupport {
         org.hl7.fhir.instance.model.api.IBaseConformance result
                 = requestBodyAndHeaders("direct://OF_TYPE", CapabilityStatement.class, headers);
 
-        LOG.debug("ofType: " + result);
+        LOG.debug("ofType: {}", result);
         assertNotNull(result, "ofType result");
         assertEquals(Enumerations.PublicationStatus.ACTIVE, ((CapabilityStatement) result).getStatus());
     }
diff --git a/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirCreateIT.java b/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirCreateIT.java
index b4391871d38..e6e71e24279 100644
--- a/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirCreateIT.java
+++ b/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirCreateIT.java
@@ -82,7 +82,7 @@ public class FhirCreateIT extends AbstractFhirTestSupport {
 
         MethodOutcome result = requestBody("direct://RESOURCE", patient);
 
-        LOG.debug("resource: " + result);
+        LOG.debug("resource: {}", result);
         assertNotNull(result, "resource result");
         assertTrue(result.getCreated());
     }
@@ -94,7 +94,7 @@ public class FhirCreateIT extends AbstractFhirTestSupport {
 
         MethodOutcome result = requestBody("direct://RESOURCE_STRING", patientString);
 
-        LOG.debug("resource: " + result);
+        LOG.debug("resource: {}", result);
         assertNotNull(result, "resource result");
         assertTrue(result.getCreated());
     }
@@ -107,7 +107,7 @@ public class FhirCreateIT extends AbstractFhirTestSupport {
         headers.put(ExtraParameters.ENCODE_XML.getHeaderName(), Boolean.TRUE);
         MethodOutcome result = requestBodyAndHeaders("direct://RESOURCE_STRING", patientString, headers);
 
-        LOG.debug("resource: " + result);
+        LOG.debug("resource: {}", result);
         assertNotNull(result, "resource result");
         assertTrue(result.getCreated());
     }
diff --git a/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirDeleteIT.java b/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirDeleteIT.java
index a0b6e87d134..f59ce70a0f1 100644
--- a/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirDeleteIT.java
+++ b/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirDeleteIT.java
@@ -51,7 +51,7 @@ public class FhirDeleteIT extends AbstractFhirTestSupport {
         // using org.hl7.fhir.instance.model.api.IBaseResource message body for single parameter "resource"
         MethodOutcome result = requestBody("direct://RESOURCE", this.patient);
 
-        LOG.debug("resource: " + result);
+        LOG.debug("resource: {}", result);
         assertNotNull(result, "resource result");
         assertFalse(patientExists());
     }
@@ -63,7 +63,7 @@ public class FhirDeleteIT extends AbstractFhirTestSupport {
         // using org.hl7.fhir.instance.model.api.IIdType message body for single parameter "id"
         MethodOutcome result = requestBody("direct://RESOURCE_BY_ID", this.patient.getIdElement());
 
-        LOG.debug("resourceById: " + result);
+        LOG.debug("resourceById: {}", result);
         assertNotNull(result, "resourceById result");
         assertFalse(patientExists());
     }
@@ -80,7 +80,7 @@ public class FhirDeleteIT extends AbstractFhirTestSupport {
 
         MethodOutcome result = requestBodyAndHeaders("direct://RESOURCE_BY_STRING_ID", null, headers);
 
-        LOG.debug("resourceById: " + result);
+        LOG.debug("resourceById: {}", result);
         assertNotNull(result, "resourceById result");
         assertFalse(patientExists());
     }
@@ -92,7 +92,7 @@ public class FhirDeleteIT extends AbstractFhirTestSupport {
         MethodOutcome result
                 = requestBody("direct://RESOURCE_CONDITIONAL_BY_URL", "Patient?given=Vincent&family=Freeman");
 
-        LOG.debug("resourceConditionalByUrl: " + result);
+        LOG.debug("resourceConditionalByUrl: {}", result);
         assertNotNull(result, "resourceConditionalByUrl result");
         assertFalse(patientExists());
     }
@@ -106,7 +106,7 @@ public class FhirDeleteIT extends AbstractFhirTestSupport {
         MethodOutcome result = requestBodyAndHeaders("direct://RESOURCE_CONDITIONAL_BY_URL",
                 "Patient?given=Vincent&family=Freeman", headers);
 
-        LOG.debug("resourceConditionalByUrl: " + result);
+        LOG.debug("resourceConditionalByUrl: {}", result);
         assertNotNull(result, "resourceConditionalByUrl result");
         assertFalse(patientExists());
     }
diff --git a/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirExtraParametersIT.java b/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirExtraParametersIT.java
index 7b3a040eda6..190902046d2 100644
--- a/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirExtraParametersIT.java
+++ b/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirExtraParametersIT.java
@@ -53,7 +53,7 @@ public class FhirExtraParametersIT extends AbstractFhirTestSupport {
 
         Bundle result = requestBodyAndHeaders("direct://SEARCH_BY_URL", url, headers);
 
-        LOG.debug("searchByUrl: " + result);
+        LOG.debug("searchByUrl: {}", result);
         assertNotNull(result, "searchByUrl result");
         Patient patient = (Patient) result.getEntry().get(0).getResource();
         assertNotNull(patient);
diff --git a/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirHistoryIT.java b/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirHistoryIT.java
index e81aff0b90b..329f416b9d8 100644
--- a/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirHistoryIT.java
+++ b/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirHistoryIT.java
@@ -56,7 +56,7 @@ public class FhirHistoryIT extends AbstractFhirTestSupport {
 
         Bundle result = requestBodyAndHeaders("direct://ON_INSTANCE", null, headers);
 
-        LOG.debug("onInstance: " + result);
+        LOG.debug("onInstance: {}", result);
         assertNotNull(result, "onInstance result");
         assertEquals(1, result.getEntry().size());
     }
@@ -68,7 +68,7 @@ public class FhirHistoryIT extends AbstractFhirTestSupport {
         headers.put("CamelFhir.count", 1);
         Bundle result = requestBodyAndHeaders("direct://ON_SERVER", null, headers);
 
-        LOG.debug("onServer: " + result);
+        LOG.debug("onServer: {}", result);
         assertNotNull(result, "onServer result");
         assertEquals(1, result.getEntry().size());
     }
@@ -85,7 +85,7 @@ public class FhirHistoryIT extends AbstractFhirTestSupport {
 
         Bundle result = requestBodyAndHeaders("direct://ON_TYPE", null, headers);
 
-        LOG.debug("onType: " + result);
+        LOG.debug("onType: {}", result);
         assertNotNull(result, "onType result");
         assertEquals(1, result.getEntry().size());
     }
@@ -104,7 +104,7 @@ public class FhirHistoryIT extends AbstractFhirTestSupport {
 
         Bundle result = requestBodyAndHeaders("direct://ON_TYPE", null, headers);
 
-        LOG.debug("onType: " + result);
+        LOG.debug("onType: {}", result);
         assertNotNull(result, "onType result");
         assertEquals(1, result.getEntry().size());
     }
diff --git a/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirLoadPageIT.java b/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirLoadPageIT.java
index d58cd15252a..2f8e3d6c995 100644
--- a/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirLoadPageIT.java
+++ b/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirLoadPageIT.java
@@ -70,7 +70,7 @@ public class FhirLoadPageIT extends AbstractFhirTestSupport {
 
         IBaseBundle result = requestBodyAndHeaders("direct://BY_URL", null, headers);
 
-        LOG.debug("byUrl: " + result);
+        LOG.debug("byUrl: {}", result);
         assertNotNull(result, "byUrl result");
     }
 
@@ -86,7 +86,7 @@ public class FhirLoadPageIT extends AbstractFhirTestSupport {
         Bundle result = requestBody("direct://NEXT", bundle);
 
         assertNotNull(result, "next result");
-        LOG.debug("next: " + result);
+        LOG.debug("next: {}", result);
     }
 
     @Test
@@ -104,7 +104,7 @@ public class FhirLoadPageIT extends AbstractFhirTestSupport {
         // using org.hl7.fhir.instance.model.api.IBaseBundle message body for single parameter "bundle"
         Bundle result = requestBody("direct://PREVIOUS", bundle);
 
-        LOG.debug("previous: " + result);
+        LOG.debug("previous: {}", result);
         assertNotNull(result, "previous result");
     }
 
@@ -125,7 +125,7 @@ public class FhirLoadPageIT extends AbstractFhirTestSupport {
         // using org.hl7.fhir.instance.model.api.IBaseBundle message body for single parameter "bundle"
         Bundle result = requestBodyAndHeaders("direct://PREVIOUS", bundle, headers);
 
-        LOG.debug("previous: " + result);
+        LOG.debug("previous: {}", result);
         assertNotNull(result, "previous result");
     }
 
diff --git a/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirMetaIT.java b/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirMetaIT.java
index 8c0127efa43..da2441ba604 100644
--- a/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirMetaIT.java
+++ b/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirMetaIT.java
@@ -60,7 +60,7 @@ public class FhirMetaIT extends AbstractFhirTestSupport {
 
         IBaseMetaType result = requestBodyAndHeaders("direct://ADD", null, headers);
 
-        LOG.debug("add: " + result);
+        LOG.debug("add: {}", result);
         assertNotNull(result, "add result");
         assertEquals(1, result.getTag().size());
     }
@@ -85,7 +85,7 @@ public class FhirMetaIT extends AbstractFhirTestSupport {
 
         IBaseMetaType result = requestBodyAndHeaders("direct://DELETE", null, headers);
 
-        LOG.debug("delete: " + result);
+        LOG.debug("delete: {}", result);
         assertNotNull(result, "delete result");
         assertEquals(0, result.getTag().size());
     }
@@ -100,7 +100,7 @@ public class FhirMetaIT extends AbstractFhirTestSupport {
 
         IBaseMetaType result = requestBodyAndHeaders("direct://GET_FROM_RESOURCE", null, headers);
 
-        LOG.debug("getFromResource: " + result);
+        LOG.debug("getFromResource: {}", result);
         assertNotNull(result, "getFromResource result");
         assertEquals(0, result.getTag().size());
     }
@@ -110,7 +110,7 @@ public class FhirMetaIT extends AbstractFhirTestSupport {
         // using Class message body for single parameter "metaType"
         IBaseMetaType result = requestBody("direct://GET_FROM_SERVER", Meta.class);
         assertNotNull(result, "getFromServer result");
-        LOG.debug("getFromServer: " + result);
+        LOG.debug("getFromServer: {}", result);
     }
 
     @Test
@@ -123,7 +123,7 @@ public class FhirMetaIT extends AbstractFhirTestSupport {
 
         IBaseMetaType result = requestBodyAndHeaders("direct://GET_FROM_TYPE", null, headers);
 
-        LOG.debug("getFromType: " + result);
+        LOG.debug("getFromType: {}", result);
         assertNotNull(result, "getFromType result");
     }
 
@@ -138,7 +138,7 @@ public class FhirMetaIT extends AbstractFhirTestSupport {
 
         Meta result = requestBodyAndHeaders("direct://GET_FROM_TYPE", null, headers);
 
-        LOG.debug("getFromType: " + result);
+        LOG.debug("getFromType: {}", result);
         assertNotNull(result, "getFromType result");
     }
 
diff --git a/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirOperationIT.java b/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirOperationIT.java
index 68c55831691..f1794cdcb5c 100644
--- a/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirOperationIT.java
+++ b/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirOperationIT.java
@@ -65,7 +65,7 @@ public class FhirOperationIT extends AbstractFhirTestSupport {
 
         final Parameters result = requestBodyAndHeaders("direct://ON_INSTANCE", null, headers);
 
-        LOG.debug("onInstance: " + result);
+        LOG.debug("onInstance: {}", result);
         assertNotNull(result, "onInstance result");
         Bundle bundle = (Bundle) result.getParameter().get(0).getResource();
         assertNotNull(bundle, "onInstance result");
@@ -92,7 +92,7 @@ public class FhirOperationIT extends AbstractFhirTestSupport {
 
         final Parameters result = requestBodyAndHeaders("direct://ON_INSTANCE_VERSION", null, headers);
 
-        LOG.debug("onInstance: " + result);
+        LOG.debug("onInstance: {}", result);
         assertNotNull(result, "onInstance result");
         Bundle bundle = (Bundle) result.getParameter().get(0).getResource();
         assertNotNull(bundle, "onInstance result");
@@ -139,7 +139,7 @@ public class FhirOperationIT extends AbstractFhirTestSupport {
         final org.hl7.fhir.instance.model.api.IBaseResource result = requestBodyAndHeaders("direct://ON_TYPE", null, headers);
 
         assertNotNull(result, "onType result");
-        LOG.debug("onType: " + result);
+        LOG.debug("onType: {}", result);
     }
 
     @Disabled("Not implemented yet in HAPI FHIR server side, see"
@@ -161,7 +161,7 @@ public class FhirOperationIT extends AbstractFhirTestSupport {
                 = requestBodyAndHeaders("direct://PROCESS_MESSAGE", null, headers);
 
         assertNotNull(result, "processMessage result");
-        LOG.debug("processMessage: " + result);
+        LOG.debug("processMessage: {}", result);
     }
 
     @Override
diff --git a/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirPatchIT.java b/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirPatchIT.java
index c92fe3560cd..f867efd6aa8 100644
--- a/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirPatchIT.java
+++ b/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirPatchIT.java
@@ -111,7 +111,7 @@ public class FhirPatchIT extends AbstractFhirTestSupport {
         MethodOutcome result = requestBodyAndHeaders("direct://PATCH_BY_URL", null, headers);
 
         assertNotNull(result, "patchByUrl result");
-        LOG.debug("patchByUrl: " + result);
+        LOG.debug("patchByUrl: {}", result);
         assertActive(result);
     }
 
@@ -136,7 +136,7 @@ public class FhirPatchIT extends AbstractFhirTestSupport {
     }
 
     private void assertActive(MethodOutcome result) {
-        LOG.debug("result: " + result);
+        LOG.debug("result: {}", result);
         IIdType id = result.getId();
 
         Patient patient = fhirClient.read().resource(Patient.class).withId(id).preferResponseType(Patient.class).execute();
diff --git a/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirReadIT.java b/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirReadIT.java
index df0cc0827bb..48748d7e3b8 100644
--- a/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirReadIT.java
+++ b/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirReadIT.java
@@ -219,7 +219,7 @@ public class FhirReadIT extends AbstractFhirTestSupport {
     }
 
     private void assertValidResponse(Patient result) {
-        LOG.debug("response: " + result);
+        LOG.debug("response: {}", result);
         assertNotNull(result, "resourceByUrl result");
         assertEquals("Freeman", result.getName().get(0).getFamily());
     }
diff --git a/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirSearchIT.java b/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirSearchIT.java
index 15d01b83626..54203905a39 100644
--- a/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirSearchIT.java
+++ b/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirSearchIT.java
@@ -45,7 +45,7 @@ public class FhirSearchIT extends AbstractFhirTestSupport {
         String url = "Patient?given=Vincent&family=Freeman&_format=json";
         Bundle result = requestBody("direct://SEARCH_BY_URL", url);
 
-        LOG.debug("searchByUrl: " + result);
+        LOG.debug("searchByUrl: {}", result);
         assertNotNull(result, "searchByUrl result");
         Patient patient = (Patient) result.getEntry().get(0).getResource();
         assertNotNull(patient);
diff --git a/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirTransactionIT.java b/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirTransactionIT.java
index bedb7431725..f59c32d5488 100644
--- a/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirTransactionIT.java
+++ b/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirTransactionIT.java
@@ -58,7 +58,7 @@ public class FhirTransactionIT extends AbstractFhirTestSupport {
 
         assertNotNull(result, "withBundle result");
         assertTrue(result.getEntry().get(0).getResponse().getStatus().contains("Created"));
-        LOG.debug("withBundle: " + result);
+        LOG.debug("withBundle: {}", result);
     }
 
     @Test
@@ -71,7 +71,7 @@ public class FhirTransactionIT extends AbstractFhirTestSupport {
 
         assertNotNull(result, "withBundle result");
         assertTrue(result.contains("Bundle"));
-        LOG.debug("withBundle: " + result);
+        LOG.debug("withBundle: {}", result);
     }
 
     @Test
@@ -86,7 +86,7 @@ public class FhirTransactionIT extends AbstractFhirTestSupport {
         List<IBaseResource> result = requestBody("direct://WITH_RESOURCES", patients);
 
         assertNotNull(result, "withResources result");
-        LOG.debug("withResources: " + result);
+        LOG.debug("withResources: {}", result);
         assertEquals(2, result.size());
     }
 
@@ -104,7 +104,7 @@ public class FhirTransactionIT extends AbstractFhirTestSupport {
         List<IBaseResource> result = requestBodyAndHeaders("direct://WITH_RESOURCES", patients, headers);
 
         assertNotNull(result, "withResources result");
-        LOG.debug("withResources: " + result);
+        LOG.debug("withResources: {}", result);
         assertEquals(2, result.size());
     }
 
diff --git a/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirUpdateIT.java b/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirUpdateIT.java
index 1f936002e53..064b636b6c4 100644
--- a/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirUpdateIT.java
+++ b/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirUpdateIT.java
@@ -63,7 +63,7 @@ public class FhirUpdateIT extends AbstractFhirTestSupport {
         MethodOutcome result = requestBodyAndHeaders("direct://RESOURCE", null, headers);
 
         assertNotNull(result, "resource result");
-        LOG.debug("resource: " + result);
+        LOG.debug("resource: {}", result);
         assertEquals(date, ((Patient) result.getResource()).getBirthDate(), "Birth date not updated!");
     }
 
@@ -81,7 +81,7 @@ public class FhirUpdateIT extends AbstractFhirTestSupport {
         MethodOutcome result = requestBodyAndHeaders("direct://RESOURCE", null, headers);
 
         assertNotNull(result, "resource result");
-        LOG.debug("resource: " + result);
+        LOG.debug("resource: {}", result);
         assertEquals(date, ((Patient) result.getResource()).getBirthDate(), "Birth date not updated!");
     }
 
@@ -101,7 +101,7 @@ public class FhirUpdateIT extends AbstractFhirTestSupport {
         MethodOutcome result = requestBodyAndHeaders("direct://RESOURCE_WITH_STRING_ID", null, headers);
 
         assertNotNull(result, "resource result");
-        LOG.debug("resource: " + result);
+        LOG.debug("resource: {}", result);
         assertEquals(date, ((Patient) result.getResource()).getBirthDate(), "Birth date not updated!");
     }
 
@@ -121,7 +121,7 @@ public class FhirUpdateIT extends AbstractFhirTestSupport {
         MethodOutcome result = requestBodyAndHeaders("direct://RESOURCE_AS_STRING", null, headers);
 
         assertNotNull(result, "resource result");
-        LOG.debug("resource: " + result);
+        LOG.debug("resource: {}", result);
         assertEquals(date, ((Patient) result.getResource()).getBirthDate(), "Birth date not updated!");
     }
 
@@ -141,7 +141,7 @@ public class FhirUpdateIT extends AbstractFhirTestSupport {
         MethodOutcome result = requestBodyAndHeaders("direct://RESOURCE_AS_STRING_WITH_STRING_ID", null, headers);
 
         assertNotNull(result, "resource result");
-        LOG.debug("resource: " + result);
+        LOG.debug("resource: {}", result);
         assertEquals(date, ((Patient) result.getResource()).getBirthDate(), "Birth date not updated!");
     }
 
@@ -162,7 +162,7 @@ public class FhirUpdateIT extends AbstractFhirTestSupport {
         MethodOutcome result = requestBodyAndHeaders("direct://RESOURCE_BY_SEARCH_URL", null, headers);
 
         assertNotNull(result, "resource result");
-        LOG.debug("resource: " + result);
+        LOG.debug("resource: {}", result);
         assertEquals(date, ((Patient) result.getResource()).getBirthDate(), "Birth date not updated!");
     }
 
@@ -183,7 +183,7 @@ public class FhirUpdateIT extends AbstractFhirTestSupport {
         MethodOutcome result = requestBodyAndHeaders("direct://RESOURCE_BY_SEARCH_URL_AND_RESOURCE_AS_STRING", null, headers);
 
         assertNotNull(result, "resource result");
-        LOG.debug("resource: " + result);
+        LOG.debug("resource: {}", result);
         assertEquals(date, ((Patient) result.getResource()).getBirthDate(), "Birth date not updated!");
     }
 
diff --git a/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirValidateIT.java b/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirValidateIT.java
index cb5a89cf3bd..d20175261e0 100644
--- a/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirValidateIT.java
+++ b/components/camel-fhir/camel-fhir-component/src/test/java/org/apache/camel/component/fhir/FhirValidateIT.java
@@ -58,7 +58,7 @@ public class FhirValidateIT extends AbstractFhirTestSupport {
         MethodOutcome result = requestBody("direct://RESOURCE", bobbyHebb);
 
         assertNotNull(result, "resource result");
-        LOG.debug("resource: " + result);
+        LOG.debug("resource: {}", result);
         OperationOutcome operationOutcome = (OperationOutcome) result.getOperationOutcome();
         assertNotNull(operationOutcome);
 
@@ -80,7 +80,7 @@ public class FhirValidateIT extends AbstractFhirTestSupport {
                 = requestBody("direct://RESOURCE_AS_STRING", this.fhirContext.newXmlParser().encodeResourceToString(bobbyHebb));
 
         assertNotNull(result, "resource result");
-        LOG.debug("resource: " + result);
+        LOG.debug("resource: {}", result);
         OperationOutcome operationOutcome = (OperationOutcome) result.getOperationOutcome();
         assertNotNull(operationOutcome);
 
diff --git a/components/camel-file/src/main/java/org/apache/camel/component/file/strategy/FileIdempotentChangedRepositoryReadLockStrategy.java b/components/camel-file/src/main/java/org/apache/camel/component/file/strategy/FileIdempotentChangedRepositoryReadLockStrategy.java
index 355630c7eaf..8ee5e6a3878 100644
--- a/components/camel-file/src/main/java/org/apache/camel/component/file/strategy/FileIdempotentChangedRepositoryReadLockStrategy.java
+++ b/components/camel-file/src/main/java/org/apache/camel/component/file/strategy/FileIdempotentChangedRepositoryReadLockStrategy.java
@@ -91,7 +91,7 @@ public class FileIdempotentChangedRepositoryReadLockStrategy extends ServiceSupp
             answer = idempotentRepository.add(exchange, key);
         } catch (Exception e) {
             if (LOG.isTraceEnabled()) {
-                LOG.trace("Cannot acquire read lock due to " + e.getMessage() + ". Will skip the file: " + file, e);
+                LOG.trace("Cannot acquire read lock due to {}. Will skip the file: {}", e.getMessage(), file, e);
             }
         }
         if (!answer) {
diff --git a/components/camel-file/src/main/java/org/apache/camel/component/file/strategy/FileIdempotentRenameRepositoryReadLockStrategy.java b/components/camel-file/src/main/java/org/apache/camel/component/file/strategy/FileIdempotentRenameRepositoryReadLockStrategy.java
index 82d653d7052..ada6a844f90 100644
--- a/components/camel-file/src/main/java/org/apache/camel/component/file/strategy/FileIdempotentRenameRepositoryReadLockStrategy.java
+++ b/components/camel-file/src/main/java/org/apache/camel/component/file/strategy/FileIdempotentRenameRepositoryReadLockStrategy.java
@@ -83,7 +83,7 @@ public class FileIdempotentRenameRepositoryReadLockStrategy extends ServiceSuppo
             answer = idempotentRepository.add(exchange, key);
         } catch (Exception e) {
             if (LOG.isTraceEnabled()) {
-                LOG.trace("Cannot acquire read lock due to " + e.getMessage() + ". Will skip the file: " + file, e);
+                LOG.trace("Cannot acquire read lock due to {}. Will skip the file: {}", e.getMessage(), file, e);
             }
         }
         if (!answer) {
diff --git a/components/camel-file/src/main/java/org/apache/camel/component/file/strategy/FileIdempotentRepositoryReadLockStrategy.java b/components/camel-file/src/main/java/org/apache/camel/component/file/strategy/FileIdempotentRepositoryReadLockStrategy.java
index 248c4a8148c..adb4098b764 100644
--- a/components/camel-file/src/main/java/org/apache/camel/component/file/strategy/FileIdempotentRepositoryReadLockStrategy.java
+++ b/components/camel-file/src/main/java/org/apache/camel/component/file/strategy/FileIdempotentRepositoryReadLockStrategy.java
@@ -80,7 +80,7 @@ public class FileIdempotentRepositoryReadLockStrategy extends ServiceSupport
             answer = idempotentRepository.add(exchange, key);
         } catch (Exception e) {
             if (LOG.isTraceEnabled()) {
-                LOG.trace("Cannot acquire read lock due to " + e.getMessage() + ". Will skip the file: " + file, e);
+                LOG.trace("Cannot acquire read lock due to {}. Will skip the file: {}", e.getMessage(), file, e);
             }
         }
         if (!answer) {
diff --git a/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/CharsetTest.java b/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/CharsetTest.java
index 06366961f08..b72a610e286 100644
--- a/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/CharsetTest.java
+++ b/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/CharsetTest.java
@@ -55,7 +55,7 @@ public class CharsetTest {
             Map<?, ?> body = in.getBody(Map.class);
             assertNotNull(body, "Should have found body as a Map but was: " + ObjectHelper.className(in.getBody()));
             assertEquals(expectedItemDesc[counter], body.get("ITEM_DESC"), "ITEM_DESC");
-            LOG.info("Result: " + counter + " = " + body);
+            LOG.info("Result: {} = {}", counter, body);
             counter++;
         }
     }
diff --git a/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/DelimitedAllowLongTest.java b/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/DelimitedAllowLongTest.java
index 440326f0a41..9849cb87400 100644
--- a/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/DelimitedAllowLongTest.java
+++ b/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/DelimitedAllowLongTest.java
@@ -62,7 +62,7 @@ public class DelimitedAllowLongTest {
             Map<?, ?> body = in.getBody(Map.class);
             assertNotNull(body, "Should have found body as a Map but was: " + ObjectHelper.className(in.getBody()));
             assertEquals(expectedItemDescriptions[counter], body.get("ITEM_DESC"), "ITEM_DESC");
-            LOG.info("Result: " + counter + " = " + body);
+            LOG.info("Result: {} = {}", counter, body);
             counter++;
         }
     }
diff --git a/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/DelimitedAllowShortAndLongTest.java b/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/DelimitedAllowShortAndLongTest.java
index 123e9ad361d..2669f100199 100644
--- a/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/DelimitedAllowShortAndLongTest.java
+++ b/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/DelimitedAllowShortAndLongTest.java
@@ -62,7 +62,7 @@ public class DelimitedAllowShortAndLongTest {
             Map<?, ?> body = in.getBody(Map.class);
             assertNotNull(body, "Should have found body as a Map but was: " + ObjectHelper.className(in.getBody()));
             assertEquals(expectedItemDescriptions[counter], body.get("ITEM_DESC"), "ITEM_DESC");
-            LOG.info("Result: " + counter + " = " + body);
+            LOG.info("Result: {} = {}", counter, body);
             counter++;
         }
     }
diff --git a/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/DelimitedAllowShortTest.java b/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/DelimitedAllowShortTest.java
index bed832328dc..019064aca3b 100644
--- a/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/DelimitedAllowShortTest.java
+++ b/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/DelimitedAllowShortTest.java
@@ -62,7 +62,7 @@ public class DelimitedAllowShortTest {
             Map<?, ?> body = in.getBody(Map.class);
             assertNotNull(body, "Should have found body as a Map but was: " + ObjectHelper.className(in.getBody()));
             assertEquals(expectedItemDescriptions[counter], body.get("ITEM_DESC"), "ITEM_DESC");
-            LOG.info("Result: " + counter + " = " + body);
+            LOG.info("Result: {} = {}", counter, body);
             counter++;
         }
     }
diff --git a/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/DelimitedTest.java b/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/DelimitedTest.java
index 1966c086a81..5ae0706caf8 100644
--- a/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/DelimitedTest.java
+++ b/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/DelimitedTest.java
@@ -55,7 +55,7 @@ public class DelimitedTest {
             Map<?, ?> body = in.getBody(Map.class);
             assertNotNull(body, "Should have found body as a Map but was: " + ObjectHelper.className(in.getBody()));
             assertEquals(expectedItemDesc[counter], body.get("ITEM_DESC"), "ITEM_DESC");
-            LOG.info("Result: " + counter + " = " + body);
+            LOG.info("Result: {} = {}", counter, body);
             counter++;
         }
     }
diff --git a/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/DelimitedWithNoDescriptorTest.java b/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/DelimitedWithNoDescriptorTest.java
index 3d381618a4f..1c3861d3cdc 100644
--- a/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/DelimitedWithNoDescriptorTest.java
+++ b/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/DelimitedWithNoDescriptorTest.java
@@ -55,7 +55,7 @@ public class DelimitedWithNoDescriptorTest {
             Map<?, ?> body = in.getBody(Map.class);
             assertNotNull(body, "Should have found body as a Map but was: " + ObjectHelper.className(in.getBody()));
             assertEquals(expectedItemDesc[counter], body.get("NAME"), "NAME");
-            LOG.info("Result: " + counter + " = " + body);
+            LOG.info("Result: {} = {}", counter, body);
             counter++;
         }
 
diff --git a/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/DelimitedWithUnmarshalTest.java b/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/DelimitedWithUnmarshalTest.java
index 4edc447c535..f80b566b4f6 100644
--- a/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/DelimitedWithUnmarshalTest.java
+++ b/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/DelimitedWithUnmarshalTest.java
@@ -55,7 +55,7 @@ public class DelimitedWithUnmarshalTest {
             Map<?, ?> body = in.getBody(Map.class);
             assertNotNull(body, "Should have found body as a Map but was: " + ObjectHelper.className(in.getBody()));
             assertEquals(expectedItemDesc[counter], body.get("ITEM_DESC"), "ITEM_DESC result(" + counter + ")");
-            LOG.info("Result: " + counter + " = " + body);
+            LOG.info("Result: {} = {}", counter, body);
             counter++;
         }
     }
diff --git a/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/FixedLengthAllowLongTest.java b/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/FixedLengthAllowLongTest.java
index 9429a85dd96..76e3523edb0 100644
--- a/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/FixedLengthAllowLongTest.java
+++ b/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/FixedLengthAllowLongTest.java
@@ -62,7 +62,7 @@ public class FixedLengthAllowLongTest {
             Map<?, ?> body = in.getBody(Map.class);
             assertNotNull(body, "Should have found body as a Map but was: " + ObjectHelper.className(in.getBody()));
             assertEquals(expectedFirstName[counter], body.get("FIRSTNAME"), "FIRSTNAME");
-            LOG.info("Result: " + counter + " = " + body);
+            LOG.info("Result: {} = {}", counter, body);
             counter++;
         }
     }
diff --git a/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/FixedLengthAllowShortAndLongTest.java b/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/FixedLengthAllowShortAndLongTest.java
index 8dbae41a492..bc517e967b8 100644
--- a/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/FixedLengthAllowShortAndLongTest.java
+++ b/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/FixedLengthAllowShortAndLongTest.java
@@ -62,7 +62,7 @@ public class FixedLengthAllowShortAndLongTest {
             Map<?, ?> body = in.getBody(Map.class);
             assertNotNull(body, "Should have found body as a Map but was: " + ObjectHelper.className(in.getBody()));
             assertEquals(expectedFirstName[counter], body.get("FIRSTNAME"), "FIRSTNAME");
-            LOG.info("Result: " + counter + " = " + body);
+            LOG.info("Result: {} = {}", counter, body);
             counter++;
         }
     }
diff --git a/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/FixedLengthAllowShortTest.java b/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/FixedLengthAllowShortTest.java
index 945cb037836..e05abfcef1b 100644
--- a/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/FixedLengthAllowShortTest.java
+++ b/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/FixedLengthAllowShortTest.java
@@ -62,7 +62,7 @@ public class FixedLengthAllowShortTest {
             Map<?, ?> body = in.getBody(Map.class);
             assertNotNull(body, "Should have found body as a Map but was: " + ObjectHelper.className(in.getBody()));
             assertEquals(expectedFirstName[counter], body.get("FIRSTNAME"), "FIRSTNAME");
-            LOG.info("Result: " + counter + " = " + body);
+            LOG.info("Result: {} = {}", counter, body);
             counter++;
         }
     }
diff --git a/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/FixedLengthTest.java b/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/FixedLengthTest.java
index d0d65333898..93e70d7f7a1 100644
--- a/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/FixedLengthTest.java
+++ b/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/FixedLengthTest.java
@@ -56,7 +56,7 @@ public class FixedLengthTest {
             Map<?, ?> body = in.getBody(Map.class);
             assertNotNull(body, "Should have found body as a Map but was: " + ObjectHelper.className(in.getBody()));
             assertEquals(expectedFirstName[counter], body.get("FIRSTNAME"), "FIRSTNAME");
-            LOG.info("Result: " + counter + " = " + body);
+            LOG.info("Result: {} = {}", counter, body);
             counter++;
         }
     }
diff --git a/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/FixedLengthWithUnmarshalTest.java b/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/FixedLengthWithUnmarshalTest.java
index 96912f1245c..f53e6d9aec8 100644
--- a/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/FixedLengthWithUnmarshalTest.java
+++ b/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/FixedLengthWithUnmarshalTest.java
@@ -55,7 +55,7 @@ public class FixedLengthWithUnmarshalTest {
             Map<?, ?> body = in.getBody(Map.class);
             assertNotNull(body, "Should have found body as a Map but was: " + ObjectHelper.className(in.getBody()));
             assertEquals(expectedFirstName[counter], body.get("FIRSTNAME"), "FIRSTNAME");
-            LOG.info("Result: " + counter + " = " + body);
+            LOG.info("Result: {} = {}", counter, body);
             counter++;
         }
     }
diff --git a/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/HeaderAndTrailerTest.java b/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/HeaderAndTrailerTest.java
index be657672b2f..095032911e1 100644
--- a/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/HeaderAndTrailerTest.java
+++ b/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/HeaderAndTrailerTest.java
@@ -62,7 +62,7 @@ public class HeaderAndTrailerTest {
             Map<?, ?> body = in.getBody(Map.class);
             assertNotNull(body, "Should have found body as a Map but was: " + ObjectHelper.className(in.getBody()));
             assertEquals(expectedFirstName[counter], body.get("FIRSTNAME"), "FIRSTNAME");
-            LOG.info("Result: " + counter + " = " + body);
+            LOG.info("Result: {} = {}", counter, body);
             counter++;
         }
 
diff --git a/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/NoSplitRowsTest.java b/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/NoSplitRowsTest.java
index fc590424499..80ebf8b643a 100644
--- a/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/NoSplitRowsTest.java
+++ b/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/NoSplitRowsTest.java
@@ -63,7 +63,7 @@ public class NoSplitRowsTest {
         int counter = 0;
         for (Map<String, String> row : data.subList(1, 5)) {
             assertEquals(expectedFirstName[counter], row.get("FIRSTNAME"), "FIRSTNAME");
-            LOG.info("Result: " + counter + " = " + row);
+            LOG.info("Result: {} = {}", counter, row);
             counter++;
         }
 
diff --git a/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/StreamedSplitTest.java b/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/StreamedSplitTest.java
index 7462ae445ff..4d14f27c30e 100644
--- a/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/StreamedSplitTest.java
+++ b/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/StreamedSplitTest.java
@@ -55,7 +55,7 @@ public class StreamedSplitTest {
             Map<?, ?> body = in.getBody(Map.class);
             assertNotNull(body, "Should have found body as a Map but was: " + ObjectHelper.className(in.getBody()));
             assertEquals(expectedItemDesc[counter], body.get("NAME"), "NAME");
-            LOG.info("Result: " + counter + " = " + body);
+            LOG.info("Result: {} = {}", counter, body);
             counter++;
         }
 
diff --git a/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/XMLNoSplitRowsTest.java b/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/XMLNoSplitRowsTest.java
index 255c5d0464b..4b526bbf6c9 100644
--- a/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/XMLNoSplitRowsTest.java
+++ b/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/XMLNoSplitRowsTest.java
@@ -86,7 +86,7 @@ public class XMLNoSplitRowsTest {
                 }
             }
             assertTrue(firstNameFound);
-            LOG.info("Result: " + counter + " = " + record);
+            LOG.info("Result: {} = {}", counter, record);
         }
 
         // assert trailer
diff --git a/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/XMLSplitRowsTest.java b/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/XMLSplitRowsTest.java
index f2d789b1f8b..f34810bd875 100644
--- a/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/XMLSplitRowsTest.java
+++ b/components/camel-flatpack/src/test/java/org/apache/camel/component/flatpack/XMLSplitRowsTest.java
@@ -85,7 +85,7 @@ public class XMLSplitRowsTest {
                 }
             }
             assertTrue(firstNameFound);
-            LOG.info("Result: " + counter + " = " + record);
+            LOG.info("Result: {} = {}", counter, record);
             counter++;
         }
 
diff --git a/components/camel-ftp/src/main/java/org/apache/camel/component/file/remote/SftpOperations.java b/components/camel-ftp/src/main/java/org/apache/camel/component/file/remote/SftpOperations.java
index 1a90b0e3dc2..c9365079152 100644
--- a/components/camel-ftp/src/main/java/org/apache/camel/component/file/remote/SftpOperations.java
+++ b/components/camel-ftp/src/main/java/org/apache/camel/component/file/remote/SftpOperations.java
@@ -537,7 +537,7 @@ public class SftpOperations implements RemoteFileOperations<SftpRemoteFile> {
             channel.rename(from, to);
             return true;
         } catch (SftpException e) {
-            LOG.debug("Cannot rename file from: " + from + " to: " + to, e);
+            LOG.debug("Cannot rename file from: {} to: {}", from, to, e);
             throw new GenericFileOperationFailedException("Cannot rename file from: " + from + " to: " + to, e);
         }
     }
diff --git a/components/camel-ftp/src/test/java/org/apache/camel/component/file/remote/integration/FromFtpExclusiveReadNoneStrategyIT.java b/components/camel-ftp/src/test/java/org/apache/camel/component/file/remote/integration/FromFtpExclusiveReadNoneStrategyIT.java
index cb88a9cbe13..80e3ee2227e 100644
--- a/components/camel-ftp/src/test/java/org/apache/camel/component/file/remote/integration/FromFtpExclusiveReadNoneStrategyIT.java
+++ b/components/camel-ftp/src/test/java/org/apache/camel/component/file/remote/integration/FromFtpExclusiveReadNoneStrategyIT.java
@@ -75,7 +75,7 @@ public class FromFtpExclusiveReadNoneStrategyIT extends FtpServerTestSupport {
         // file currently in progress of being written - so we get only the
         // Hello World part
         String body = mock.getReceivedExchanges().get(0).getIn().getBody(String.class);
-        LOG.debug("Body is: " + body);
+        LOG.debug("Body is: {}", body);
         assertFalse(body.endsWith("Bye World"), "Should not wait and read the entire file");
     }
 
diff --git a/components/camel-ftp/src/test/java/org/apache/camel/component/file/remote/integration/FtpChangedReadLockIT.java b/components/camel-ftp/src/test/java/org/apache/camel/component/file/remote/integration/FtpChangedReadLockIT.java
index d967dc17595..2d5de32ab51 100644
--- a/components/camel-ftp/src/test/java/org/apache/camel/component/file/remote/integration/FtpChangedReadLockIT.java
+++ b/components/camel-ftp/src/test/java/org/apache/camel/component/file/remote/integration/FtpChangedReadLockIT.java
@@ -69,7 +69,7 @@ public class FtpChangedReadLockIT extends FtpServerTestSupport {
         FileOutputStream fos = new FileOutputStream(service.ftpFile("changed/slowfile.dat").toFile(), true);
         for (int i = 0; i < 20; i++) {
             fos.write(("Line " + i + LS).getBytes());
-            LOG.debug("Writing line " + i);
+            LOG.debug("Writing line {}", i);
             Thread.sleep(200);
         }
 
diff --git a/components/camel-ftp/src/test/java/org/apache/camel/component/file/remote/integration/FtpChangedRootDirReadLockIT.java b/components/camel-ftp/src/test/java/org/apache/camel/component/file/remote/integration/FtpChangedRootDirReadLockIT.java
index 5a7847ea069..36c950e4e33 100644
--- a/components/camel-ftp/src/test/java/org/apache/camel/component/file/remote/integration/FtpChangedRootDirReadLockIT.java
+++ b/components/camel-ftp/src/test/java/org/apache/camel/component/file/remote/integration/FtpChangedRootDirReadLockIT.java
@@ -70,7 +70,7 @@ public class FtpChangedRootDirReadLockIT extends FtpServerTestSupport {
         FileOutputStream fos = new FileOutputStream(service.ftpFile("slowfile.dat").toFile(), true);
         for (int i = 0; i < 20; i++) {
             fos.write(("Line " + i + LS).getBytes());
-            LOG.debug("Writing line " + i);
+            LOG.debug("Writing line {}", i);
             Thread.sleep(200);
         }
 
diff --git a/components/camel-ftp/src/test/java/org/apache/camel/component/file/remote/sftp/integration/SftpChangedReadLockIT.java b/components/camel-ftp/src/test/java/org/apache/camel/component/file/remote/sftp/integration/SftpChangedReadLockIT.java
index 1e6c5df5406..3c16c393a2b 100644
--- a/components/camel-ftp/src/test/java/org/apache/camel/component/file/remote/sftp/integration/SftpChangedReadLockIT.java
+++ b/components/camel-ftp/src/test/java/org/apache/camel/component/file/remote/sftp/integration/SftpChangedReadLockIT.java
@@ -72,7 +72,7 @@ public class SftpChangedReadLockIT extends SftpServerTestSupport {
         FileOutputStream fos = new FileOutputStream(ftpFile("changed/slowfile.dat").toFile(), true);
         for (int i = 0; i < 20; i++) {
             fos.write(("Line " + i + LS).getBytes());
-            LOG.debug("Writing line " + i);
+            LOG.debug("Writing line {}", i);
             Thread.sleep(200);
         }
         fos.flush();