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/12/06 22:42:19 UTC

(camel) branch main updated: (chores) components: fixed checkstyle

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 8a923555f57 (chores) components: fixed checkstyle
8a923555f57 is described below

commit 8a923555f57702289571a3cc37fab2730c65f8b5
Author: Otavio Rodolfo Piske <an...@gmail.com>
AuthorDate: Wed Dec 6 20:18:54 2023 +0000

    (chores) components: fixed checkstyle
---
 .../component/couchbase/integration/ConsumeMessagesWithLimitIT.java | 4 ++--
 .../component/couchbase/integration/ConsumeResumeStrategyIT.java    | 4 ++--
 .../component/couchbase/integration/ProduceMessagesSimpleIT.java    | 4 ++--
 .../couchbase/integration/ProduceMessagesWithAutoIDIT.java          | 4 ++--
 .../camel/component/couchbase/integration/RemoveMessagesIT.java     | 4 ++--
 .../java/org/apache/camel/component/jms/AggregatedJmsRouteTest.java | 5 ++---
 .../org/apache/camel/component/jms/issues/TempReplyToIssueTest.java | 2 +-
 .../org/apache/camel/component/kafka/consumer/CommitManager.java    | 3 ++-
 .../kafka/consumer/support/KafkaRecordProcessorFacade.java          | 6 ++++--
 .../camel/processor/resume/kafka/SingleNodeKafkaResumeStrategy.java | 6 ++++--
 .../component/springrabbit/DefaultMessagePropertiesConverter.java   | 1 -
 11 files changed, 23 insertions(+), 20 deletions(-)

diff --git a/components/camel-couchbase/src/test/java/org/apache/camel/component/couchbase/integration/ConsumeMessagesWithLimitIT.java b/components/camel-couchbase/src/test/java/org/apache/camel/component/couchbase/integration/ConsumeMessagesWithLimitIT.java
index bb348c05ecb..8fc06cabd98 100644
--- a/components/camel-couchbase/src/test/java/org/apache/camel/component/couchbase/integration/ConsumeMessagesWithLimitIT.java
+++ b/components/camel-couchbase/src/test/java/org/apache/camel/component/couchbase/integration/ConsumeMessagesWithLimitIT.java
@@ -30,10 +30,10 @@ import org.junit.jupiter.api.condition.DisabledIfSystemProperty;
 
 @DisabledIfSystemProperties({
         @DisabledIfSystemProperty(named = "ci.env.name", matches = "apache.org",
-                disabledReason = "Apache CI nodes are too resource constrained for this test"),
+                                  disabledReason = "Apache CI nodes are too resource constrained for this test"),
         @DisabledIfSystemProperty(named = "ci.env.name", matches = "github.com", disabledReason = "Flaky on GitHub Actions"),
         @DisabledIfSystemProperty(named = "couchbase.enable.it", matches = "false",
-                disabledReason = "Too resource intensive for most systems to run reliably"),
+                                  disabledReason = "Too resource intensive for most systems to run reliably"),
 })
 @Tags({ @Tag("couchbase-71") })
 public class ConsumeMessagesWithLimitIT extends CouchbaseIntegrationTestBase {
diff --git a/components/camel-couchbase/src/test/java/org/apache/camel/component/couchbase/integration/ConsumeResumeStrategyIT.java b/components/camel-couchbase/src/test/java/org/apache/camel/component/couchbase/integration/ConsumeResumeStrategyIT.java
index 17693e1cc51..899b87458c5 100644
--- a/components/camel-couchbase/src/test/java/org/apache/camel/component/couchbase/integration/ConsumeResumeStrategyIT.java
+++ b/components/camel-couchbase/src/test/java/org/apache/camel/component/couchbase/integration/ConsumeResumeStrategyIT.java
@@ -40,10 +40,10 @@ import static org.awaitility.Awaitility.await;
 
 @DisabledIfSystemProperties({
         @DisabledIfSystemProperty(named = "ci.env.name", matches = "apache.org",
-                disabledReason = "Apache CI nodes are too resource constrained for this test"),
+                                  disabledReason = "Apache CI nodes are too resource constrained for this test"),
         @DisabledIfSystemProperty(named = "ci.env.name", matches = "github.com", disabledReason = "Flaky on GitHub Actions"),
         @DisabledIfSystemProperty(named = "couchbase.enable.it", matches = "false",
-                disabledReason = "Too resource intensive for most systems to run reliably"),
+                                  disabledReason = "Too resource intensive for most systems to run reliably"),
 })
 @Tags({ @Tag("couchbase-71") })
 public class ConsumeResumeStrategyIT extends CouchbaseIntegrationTestBase {
diff --git a/components/camel-couchbase/src/test/java/org/apache/camel/component/couchbase/integration/ProduceMessagesSimpleIT.java b/components/camel-couchbase/src/test/java/org/apache/camel/component/couchbase/integration/ProduceMessagesSimpleIT.java
index 4513b7e3729..690c17a8d6e 100644
--- a/components/camel-couchbase/src/test/java/org/apache/camel/component/couchbase/integration/ProduceMessagesSimpleIT.java
+++ b/components/camel-couchbase/src/test/java/org/apache/camel/component/couchbase/integration/ProduceMessagesSimpleIT.java
@@ -27,10 +27,10 @@ import org.junit.jupiter.api.condition.DisabledIfSystemProperty;
 
 @DisabledIfSystemProperties({
         @DisabledIfSystemProperty(named = "ci.env.name", matches = "apache.org",
-                disabledReason = "Apache CI nodes are too resource constrained for this test"),
+                                  disabledReason = "Apache CI nodes are too resource constrained for this test"),
         @DisabledIfSystemProperty(named = "ci.env.name", matches = "github.com", disabledReason = "Flaky on GitHub Actions"),
         @DisabledIfSystemProperty(named = "couchbase.enable.it", matches = "false",
-                disabledReason = "Too resource intensive for most systems to run reliably"),
+                                  disabledReason = "Too resource intensive for most systems to run reliably"),
 })
 @Tags({ @Tag("couchbase-7") })
 public class ProduceMessagesSimpleIT extends CouchbaseIntegrationTestBase {
diff --git a/components/camel-couchbase/src/test/java/org/apache/camel/component/couchbase/integration/ProduceMessagesWithAutoIDIT.java b/components/camel-couchbase/src/test/java/org/apache/camel/component/couchbase/integration/ProduceMessagesWithAutoIDIT.java
index 5d3e7f13fe5..516db0aabfd 100644
--- a/components/camel-couchbase/src/test/java/org/apache/camel/component/couchbase/integration/ProduceMessagesWithAutoIDIT.java
+++ b/components/camel-couchbase/src/test/java/org/apache/camel/component/couchbase/integration/ProduceMessagesWithAutoIDIT.java
@@ -26,10 +26,10 @@ import org.junit.jupiter.api.condition.DisabledIfSystemProperty;
 
 @DisabledIfSystemProperties({
         @DisabledIfSystemProperty(named = "ci.env.name", matches = "apache.org",
-                disabledReason = "Apache CI nodes are too resource constrained for this test"),
+                                  disabledReason = "Apache CI nodes are too resource constrained for this test"),
         @DisabledIfSystemProperty(named = "ci.env.name", matches = "github.com", disabledReason = "Flaky on GitHub Actions"),
         @DisabledIfSystemProperty(named = "couchbase.enable.it", matches = "false",
-                disabledReason = "Too resource intensive for most systems to run reliably"),
+                                  disabledReason = "Too resource intensive for most systems to run reliably"),
 })
 @Tags({ @Tag("couchbase-7") })
 public class ProduceMessagesWithAutoIDIT extends CouchbaseIntegrationTestBase {
diff --git a/components/camel-couchbase/src/test/java/org/apache/camel/component/couchbase/integration/RemoveMessagesIT.java b/components/camel-couchbase/src/test/java/org/apache/camel/component/couchbase/integration/RemoveMessagesIT.java
index 947ec8723a8..420682cd05c 100644
--- a/components/camel-couchbase/src/test/java/org/apache/camel/component/couchbase/integration/RemoveMessagesIT.java
+++ b/components/camel-couchbase/src/test/java/org/apache/camel/component/couchbase/integration/RemoveMessagesIT.java
@@ -30,10 +30,10 @@ import static org.apache.camel.component.couchbase.CouchbaseConstants.HEADER_ID;
 
 @DisabledIfSystemProperties({
         @DisabledIfSystemProperty(named = "ci.env.name", matches = "apache.org",
-                disabledReason = "Apache CI nodes are too resource constrained for this test"),
+                                  disabledReason = "Apache CI nodes are too resource constrained for this test"),
         @DisabledIfSystemProperty(named = "ci.env.name", matches = "github.com", disabledReason = "Flaky on GitHub Actions"),
         @DisabledIfSystemProperty(named = "couchbase.enable.it", matches = "false",
-                disabledReason = "Too resource intensive for most systems to run reliably"),
+                                  disabledReason = "Too resource intensive for most systems to run reliably"),
 })
 @Tags({ @Tag("couchbase-7") })
 public class RemoveMessagesIT extends CouchbaseIntegrationTestBase {
diff --git a/components/camel-jms/src/test/java/org/apache/camel/component/jms/AggregatedJmsRouteTest.java b/components/camel-jms/src/test/java/org/apache/camel/component/jms/AggregatedJmsRouteTest.java
index f01573faee2..a41dd1bad21 100644
--- a/components/camel-jms/src/test/java/org/apache/camel/component/jms/AggregatedJmsRouteTest.java
+++ b/components/camel-jms/src/test/java/org/apache/camel/component/jms/AggregatedJmsRouteTest.java
@@ -16,8 +16,6 @@
  */
 package org.apache.camel.component.jms;
 
-import static org.junit.jupiter.api.Assertions.fail;
-
 import org.apache.camel.CamelContext;
 import org.apache.camel.ConsumerTemplate;
 import org.apache.camel.Exchange;
@@ -35,6 +33,8 @@ import org.junit.jupiter.api.extension.RegisterExtension;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
+import static org.junit.jupiter.api.Assertions.fail;
+
 public class AggregatedJmsRouteTest extends AbstractJMSTest {
 
     @Order(2)
@@ -101,7 +101,6 @@ public class AggregatedJmsRouteTest extends AbstractJMSTest {
                     return newExchange;
                 }).completionTimeout(2000L).to("mock:result");
 
-
                 from(multicastEndpointUri).to("jms:queue:AggregatedJmsRouteTestQueuePoint1",
                         "jms:queue:AggregatedJmsRouteTestQueuePoint2", "jms:queue:AggregatedJmsRouteTestQueuePoint3");
                 from("jms:queue:AggregatedJmsRouteTestQueuePoint1").process(new MyProcessor())
diff --git a/components/camel-jms/src/test/java/org/apache/camel/component/jms/issues/TempReplyToIssueTest.java b/components/camel-jms/src/test/java/org/apache/camel/component/jms/issues/TempReplyToIssueTest.java
index 4b2e1c13dee..1dd08ce9351 100644
--- a/components/camel-jms/src/test/java/org/apache/camel/component/jms/issues/TempReplyToIssueTest.java
+++ b/components/camel-jms/src/test/java/org/apache/camel/component/jms/issues/TempReplyToIssueTest.java
@@ -16,8 +16,8 @@
  */
 package org.apache.camel.component.jms.issues;
 
-
 import jakarta.jms.Destination;
+
 import org.apache.camel.Body;
 import org.apache.camel.CamelContext;
 import org.apache.camel.ConsumerTemplate;
diff --git a/components/camel-kafka/src/main/java/org/apache/camel/component/kafka/consumer/CommitManager.java b/components/camel-kafka/src/main/java/org/apache/camel/component/kafka/consumer/CommitManager.java
index c852f6a5fd2..a8b8a776aa3 100644
--- a/components/camel-kafka/src/main/java/org/apache/camel/component/kafka/consumer/CommitManager.java
+++ b/components/camel-kafka/src/main/java/org/apache/camel/component/kafka/consumer/CommitManager.java
@@ -23,7 +23,8 @@ import org.apache.kafka.common.TopicPartition;
 
 public interface CommitManager {
 
-    KafkaManualCommit getManualCommit(Exchange exchange, TopicPartition partition, ConsumerRecord<Object, Object> consumerRecord);
+    KafkaManualCommit getManualCommit(
+            Exchange exchange, TopicPartition partition, ConsumerRecord<Object, Object> consumerRecord);
 
     /**
      * Commits everything that has been cached
diff --git a/components/camel-kafka/src/main/java/org/apache/camel/component/kafka/consumer/support/KafkaRecordProcessorFacade.java b/components/camel-kafka/src/main/java/org/apache/camel/component/kafka/consumer/support/KafkaRecordProcessorFacade.java
index 5c7060400d7..f6317510fd9 100644
--- a/components/camel-kafka/src/main/java/org/apache/camel/component/kafka/consumer/support/KafkaRecordProcessorFacade.java
+++ b/components/camel-kafka/src/main/java/org/apache/camel/component/kafka/consumer/support/KafkaRecordProcessorFacade.java
@@ -79,14 +79,16 @@ public class KafkaRecordProcessorFacade {
             while (!lastResult.isBreakOnErrorHit() && recordIterator.hasNext() && !isStopping()) {
                 ConsumerRecord<Object, Object> consumerRecord = recordIterator.next();
 
-                LOG.debug("Processing record on partition {} with offset {}", consumerRecord.partition(), consumerRecord.offset());
+                LOG.debug("Processing record on partition {} with offset {}", consumerRecord.partition(),
+                        consumerRecord.offset());
 
                 lastResult = processRecord(partition, partitionIterator.hasNext(), recordIterator.hasNext(), lastResult,
                         kafkaRecordProcessor, consumerRecord);
 
                 LOG.debug(
                         "Processed record on partition {} with offset {} and got ProcessingResult for partition {} and offset {}",
-                        consumerRecord.partition(), consumerRecord.offset(), lastResult.getPartition(), lastResult.getPartitionLastOffset());
+                        consumerRecord.partition(), consumerRecord.offset(), lastResult.getPartition(),
+                        lastResult.getPartitionLastOffset());
 
                 if (consumerListener != null) {
                     if (!consumerListener.afterProcess(lastResult)) {
diff --git a/components/camel-kafka/src/main/java/org/apache/camel/processor/resume/kafka/SingleNodeKafkaResumeStrategy.java b/components/camel-kafka/src/main/java/org/apache/camel/processor/resume/kafka/SingleNodeKafkaResumeStrategy.java
index 94be16f6258..1349065e75f 100644
--- a/components/camel-kafka/src/main/java/org/apache/camel/processor/resume/kafka/SingleNodeKafkaResumeStrategy.java
+++ b/components/camel-kafka/src/main/java/org/apache/camel/processor/resume/kafka/SingleNodeKafkaResumeStrategy.java
@@ -108,7 +108,8 @@ public class SingleNodeKafkaResumeStrategy implements KafkaResumeStrategy, Camel
      *
      */
     protected void produce(byte[] key, byte[] message, UpdateCallBack updateCallBack) {
-        ProducerRecord<byte[], byte[]> producerRecord = new ProducerRecord<>(resumeStrategyConfiguration.getTopic(), key, message);
+        ProducerRecord<byte[], byte[]> producerRecord
+                = new ProducerRecord<>(resumeStrategyConfiguration.getTopic(), key, message);
 
         producer.send(producerRecord, (recordMetadata, e) -> {
             if (e != null) {
@@ -243,7 +244,8 @@ public class SingleNodeKafkaResumeStrategy implements KafkaResumeStrategy, Camel
                             consumerRecord.timestampType(), value);
                 }
 
-                if (!deserializable.deserialize(ByteBuffer.wrap(consumerRecord.key()), ByteBuffer.wrap(consumerRecord.value()))) {
+                if (!deserializable.deserialize(ByteBuffer.wrap(consumerRecord.key()),
+                        ByteBuffer.wrap(consumerRecord.value()))) {
                     LOG.warn("Deserializer indicates that this is the last record to deserialize");
                 }
             }
diff --git a/components/camel-spring-rabbitmq/src/main/java/org/apache/camel/component/springrabbit/DefaultMessagePropertiesConverter.java b/components/camel-spring-rabbitmq/src/main/java/org/apache/camel/component/springrabbit/DefaultMessagePropertiesConverter.java
index 4ec4eb62832..717c572fed6 100644
--- a/components/camel-spring-rabbitmq/src/main/java/org/apache/camel/component/springrabbit/DefaultMessagePropertiesConverter.java
+++ b/components/camel-spring-rabbitmq/src/main/java/org/apache/camel/component/springrabbit/DefaultMessagePropertiesConverter.java
@@ -21,7 +21,6 @@ import java.util.HashMap;
 import java.util.Map;
 import java.util.Set;
 
-import org.apache.camel.CamelContext;
 import org.apache.camel.Exchange;
 import org.apache.camel.Message;
 import org.apache.camel.spi.HeaderFilterStrategy;