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 2022/03/08 16:06:52 UTC

[camel] branch main updated (778a35d -> ed4107a)

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

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


    from 778a35d  CAMEL-17763: cleaned up unused exceptions in camel-undertow
     new 85ec6ae  CAMEL-17763: cleaned up unused exceptions in camel-azure-cosmosdb
     new 054d7b5  CAMEL-17763: cleaned up unused exceptions in camel-azure-eventhubs
     new 5564bcd  CAMEL-17763: cleaned up unused exceptions in camel-azure-servicebus
     new 2f68d8e  CAMEL-17763: cleaned up unused exceptions in camel-azure-storage-blob
     new 2a13a9c  CAMEL-17763: cleaned up unused exceptions in camel-azure-storage-datalake
     new ed4107a  CAMEL-17763: cleaned up unused exceptions in camel-azure-storage-queue

The 6 revisions listed above as "new" are entirely new to this
repository and will be described in separate emails.  The revisions
listed as "add" were already present in the repository and have only
been added to this reference.


Summary of changes:
 .../component/azure/cosmosdb/integration/CosmosDbConsumerIT.java   | 4 ++--
 .../component/azure/cosmosdb/integration/CosmosDbProducerIT.java   | 4 ++--
 .../integration/operations/CosmosDbContainerOperationsIT.java      | 2 +-
 .../camel/component/azure/eventhubs/EventHubsComponentTest.java    | 2 +-
 .../component/azure/eventhubs/integration/EventHubsConsumerIT.java | 4 ++--
 .../component/azure/eventhubs/integration/EventHubsProducerIT.java | 4 ++--
 .../camel/component/azure/servicebus/ServiceBusEndpointTest.java   | 2 +-
 .../azure/servicebus/integration/ServiceBusConsumerTest.java       | 4 ++--
 .../azure/servicebus/integration/ServiceBusProducerTest.java       | 4 ++--
 .../camel/component/azure/storage/blob/BlobComponentTest.java      | 6 +++---
 .../azure/storage/blob/integration/BlobChangeFeedOperationsIT.java | 4 ++--
 .../azure/storage/blob/integration/BlobCopyProducerIt.java         | 6 +++---
 .../component/azure/storage/blob/integration/BlobProducerIT.java   | 7 +++----
 .../azure/storage/datalake/integration/DataLakeProducerIT.java     | 4 ++--
 .../camel/component/azure/storage/queue/QueueComponentTest.java    | 2 +-
 .../apache/camel/component/azure/storage/queue/QueueTestUtils.java | 2 +-
 .../azure/storage/queue/integration/StorageQueueConsumerIT.java    | 4 ++--
 .../azure/storage/queue/integration/StorageQueueProducerIT.java    | 6 +++---
 18 files changed, 35 insertions(+), 36 deletions(-)

[camel] 01/06: CAMEL-17763: cleaned up unused exceptions in camel-azure-cosmosdb

Posted by or...@apache.org.
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

commit 85ec6ae1d4ca5fd562d40d1ea7f69d671d8845c0
Author: Otavio Rodolfo Piske <an...@gmail.com>
AuthorDate: Tue Mar 8 13:50:22 2022 +0100

    CAMEL-17763: cleaned up unused exceptions in camel-azure-cosmosdb
---
 .../component/azure/cosmosdb/integration/CosmosDbConsumerIT.java      | 4 ++--
 .../component/azure/cosmosdb/integration/CosmosDbProducerIT.java      | 4 ++--
 .../integration/operations/CosmosDbContainerOperationsIT.java         | 2 +-
 3 files changed, 5 insertions(+), 5 deletions(-)

diff --git a/components/camel-azure/camel-azure-cosmosdb/src/test/java/org/apache/camel/component/azure/cosmosdb/integration/CosmosDbConsumerIT.java b/components/camel-azure/camel-azure-cosmosdb/src/test/java/org/apache/camel/component/azure/cosmosdb/integration/CosmosDbConsumerIT.java
index 8c43080..9993c8c 100644
--- a/components/camel-azure/camel-azure-cosmosdb/src/test/java/org/apache/camel/component/azure/cosmosdb/integration/CosmosDbConsumerIT.java
+++ b/components/camel-azure/camel-azure-cosmosdb/src/test/java/org/apache/camel/component/azure/cosmosdb/integration/CosmosDbConsumerIT.java
@@ -120,10 +120,10 @@ class CosmosDbConsumerIT extends BaseCamelCosmosDbTestSupport {
     }
 
     @Override
-    protected RouteBuilder createRouteBuilder() throws Exception {
+    protected RouteBuilder createRouteBuilder() {
         return new RouteBuilder() {
             @Override
-            public void configure() throws Exception {
+            public void configure() {
                 from(String.format(
                         "azure-cosmosdb://%s/%s?leaseDatabaseName=%s&createLeaseDatabaseIfNotExists=true&createLeaseContainerIfNotExists=true",
                         DATABASE_NAME, containerName, leaseDatabaseName))
diff --git a/components/camel-azure/camel-azure-cosmosdb/src/test/java/org/apache/camel/component/azure/cosmosdb/integration/CosmosDbProducerIT.java b/components/camel-azure/camel-azure-cosmosdb/src/test/java/org/apache/camel/component/azure/cosmosdb/integration/CosmosDbProducerIT.java
index 7842167..b8f2d0d 100644
--- a/components/camel-azure/camel-azure-cosmosdb/src/test/java/org/apache/camel/component/azure/cosmosdb/integration/CosmosDbProducerIT.java
+++ b/components/camel-azure/camel-azure-cosmosdb/src/test/java/org/apache/camel/component/azure/cosmosdb/integration/CosmosDbProducerIT.java
@@ -430,10 +430,10 @@ public class CosmosDbProducerIT extends BaseCamelCosmosDbTestSupport {
     }
 
     @Override
-    protected RouteBuilder createRouteBuilder() throws Exception {
+    protected RouteBuilder createRouteBuilder() {
         return new RouteBuilder() {
             @Override
-            public void configure() throws Exception {
+            public void configure() {
                 from("direct:listDatabases").to("azure-cosmosdb://?operation=listDatabases").to(resultName);
                 from("direct:createDatabase").to("azure-cosmosdb://?operation=createDatabase").to(resultName);
                 from("direct:deleteDatabase").to("azure-cosmosdb://?operation=deleteDatabase").to(resultName);
diff --git a/components/camel-azure/camel-azure-cosmosdb/src/test/java/org/apache/camel/component/azure/cosmosdb/integration/operations/CosmosDbContainerOperationsIT.java b/components/camel-azure/camel-azure-cosmosdb/src/test/java/org/apache/camel/component/azure/cosmosdb/integration/operations/CosmosDbContainerOperationsIT.java
index f360513..31e697f 100644
--- a/components/camel-azure/camel-azure-cosmosdb/src/test/java/org/apache/camel/component/azure/cosmosdb/integration/operations/CosmosDbContainerOperationsIT.java
+++ b/components/camel-azure/camel-azure-cosmosdb/src/test/java/org/apache/camel/component/azure/cosmosdb/integration/operations/CosmosDbContainerOperationsIT.java
@@ -295,7 +295,7 @@ class CosmosDbContainerOperationsIT {
     }
 
     @Test
-    void testCaptureChangeFeed() throws InterruptedException {
+    void testCaptureChangeFeed() {
         // we create our lease container first with our lease database
         final Mono<CosmosAsyncContainer> leaseContainer = CosmosDbOperationsBuilder.withClient(clientWrapper)
                 .withContainerName("camel-lease")

[camel] 02/06: CAMEL-17763: cleaned up unused exceptions in camel-azure-eventhubs

Posted by or...@apache.org.
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

commit 054d7b5d9b06bc1e5428ba85c23adb8f48175267
Author: Otavio Rodolfo Piske <an...@gmail.com>
AuthorDate: Tue Mar 8 13:50:23 2022 +0100

    CAMEL-17763: cleaned up unused exceptions in camel-azure-eventhubs
---
 .../camel/component/azure/eventhubs/EventHubsComponentTest.java       | 2 +-
 .../component/azure/eventhubs/integration/EventHubsConsumerIT.java    | 4 ++--
 .../component/azure/eventhubs/integration/EventHubsProducerIT.java    | 4 ++--
 3 files changed, 5 insertions(+), 5 deletions(-)

diff --git a/components/camel-azure/camel-azure-eventhubs/src/test/java/org/apache/camel/component/azure/eventhubs/EventHubsComponentTest.java b/components/camel-azure/camel-azure-eventhubs/src/test/java/org/apache/camel/component/azure/eventhubs/EventHubsComponentTest.java
index 02ec74e..1f6b7f9 100644
--- a/components/camel-azure/camel-azure-eventhubs/src/test/java/org/apache/camel/component/azure/eventhubs/EventHubsComponentTest.java
+++ b/components/camel-azure/camel-azure-eventhubs/src/test/java/org/apache/camel/component/azure/eventhubs/EventHubsComponentTest.java
@@ -31,7 +31,7 @@ import static org.junit.jupiter.api.Assertions.assertTrue;
 class EventHubsComponentTest extends CamelTestSupport {
 
     @Test
-    public void testCreateEndpointWithNoEventHubsNameOrNameSpace() throws Exception {
+    public void testCreateEndpointWithNoEventHubsNameOrNameSpace() {
         ResolveEndpointFailedException exception = assertThrows(ResolveEndpointFailedException.class,
                 () -> context.getEndpoint("azure-eventhubs:?sharedAccessKey=string&sharedAccessName=name"));
 
diff --git a/components/camel-azure/camel-azure-eventhubs/src/test/java/org/apache/camel/component/azure/eventhubs/integration/EventHubsConsumerIT.java b/components/camel-azure/camel-azure-eventhubs/src/test/java/org/apache/camel/component/azure/eventhubs/integration/EventHubsConsumerIT.java
index 3ed0bfe..cab2217 100644
--- a/components/camel-azure/camel-azure-eventhubs/src/test/java/org/apache/camel/component/azure/eventhubs/integration/EventHubsConsumerIT.java
+++ b/components/camel-azure/camel-azure-eventhubs/src/test/java/org/apache/camel/component/azure/eventhubs/integration/EventHubsConsumerIT.java
@@ -124,10 +124,10 @@ class EventHubsConsumerIT extends CamelTestSupport {
     }
 
     @Override
-    protected RouteBuilder createRouteBuilder() throws Exception {
+    protected RouteBuilder createRouteBuilder() {
         return new RouteBuilder() {
             @Override
-            public void configure() throws Exception {
+            public void configure() {
                 from("azure-eventhubs:?"
                      + "connectionString=RAW({{connectionString}})"
                      + "&blobContainerName=" + containerName + "&eventPosition=#eventPosition"
diff --git a/components/camel-azure/camel-azure-eventhubs/src/test/java/org/apache/camel/component/azure/eventhubs/integration/EventHubsProducerIT.java b/components/camel-azure/camel-azure-eventhubs/src/test/java/org/apache/camel/component/azure/eventhubs/integration/EventHubsProducerIT.java
index fb62262..097ae11 100644
--- a/components/camel-azure/camel-azure-eventhubs/src/test/java/org/apache/camel/component/azure/eventhubs/integration/EventHubsProducerIT.java
+++ b/components/camel-azure/camel-azure-eventhubs/src/test/java/org/apache/camel/component/azure/eventhubs/integration/EventHubsProducerIT.java
@@ -132,10 +132,10 @@ class EventHubsProducerIT extends CamelTestSupport {
     }
 
     @Override
-    protected RouteBuilder createRouteBuilder() throws Exception {
+    protected RouteBuilder createRouteBuilder() {
         return new RouteBuilder() {
             @Override
-            public void configure() throws Exception {
+            public void configure() {
                 from("direct:sendAsync")
                         .to("azure-eventhubs:?connectionString=RAW({{connectionString}})")
                         .to(result);

[camel] 05/06: CAMEL-17763: cleaned up unused exceptions in camel-azure-storage-datalake

Posted by or...@apache.org.
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

commit 2a13a9ca4ab174b9ebb8cdae319eb6ffbfd5074e
Author: Otavio Rodolfo Piske <an...@gmail.com>
AuthorDate: Tue Mar 8 13:50:23 2022 +0100

    CAMEL-17763: cleaned up unused exceptions in camel-azure-storage-datalake
---
 .../azure/storage/datalake/integration/DataLakeProducerIT.java        | 4 ++--
 1 file changed, 2 insertions(+), 2 deletions(-)

diff --git a/components/camel-azure/camel-azure-storage-datalake/src/test/java/org/apache/camel/component/azure/storage/datalake/integration/DataLakeProducerIT.java b/components/camel-azure/camel-azure-storage-datalake/src/test/java/org/apache/camel/component/azure/storage/datalake/integration/DataLakeProducerIT.java
index ff193de..cc5bd4e 100644
--- a/components/camel-azure/camel-azure-storage-datalake/src/test/java/org/apache/camel/component/azure/storage/datalake/integration/DataLakeProducerIT.java
+++ b/components/camel-azure/camel-azure-storage-datalake/src/test/java/org/apache/camel/component/azure/storage/datalake/integration/DataLakeProducerIT.java
@@ -46,7 +46,7 @@ public class DataLakeProducerIT extends Base {
     }
 
     @Test
-    void testConsumer() throws Exception {
+    void testConsumer() {
 
         {
             @SuppressWarnings("unchecked")
@@ -105,7 +105,7 @@ public class DataLakeProducerIT extends Base {
     }
 
     @Test
-    void testHeaderPreservation() throws InterruptedException {
+    void testHeaderPreservation() {
         Exchange result = template.send(componentUri(fileSystemName, DataLakeOperationsDefinition.listFileSystem),
                 exchange -> {
                     exchange.getIn().setHeader("DoNotDelete", "keep me");

[camel] 04/06: CAMEL-17763: cleaned up unused exceptions in camel-azure-storage-blob

Posted by or...@apache.org.
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

commit 2f68d8e0b1a2696b1179576bc5904662007d7b3e
Author: Otavio Rodolfo Piske <an...@gmail.com>
AuthorDate: Tue Mar 8 13:50:23 2022 +0100

    CAMEL-17763: cleaned up unused exceptions in camel-azure-storage-blob
---
 .../camel/component/azure/storage/blob/BlobComponentTest.java      | 6 +++---
 .../azure/storage/blob/integration/BlobChangeFeedOperationsIT.java | 4 ++--
 .../azure/storage/blob/integration/BlobCopyProducerIt.java         | 6 +++---
 .../component/azure/storage/blob/integration/BlobProducerIT.java   | 7 +++----
 4 files changed, 11 insertions(+), 12 deletions(-)

diff --git a/components/camel-azure/camel-azure-storage-blob/src/test/java/org/apache/camel/component/azure/storage/blob/BlobComponentTest.java b/components/camel-azure/camel-azure-storage-blob/src/test/java/org/apache/camel/component/azure/storage/blob/BlobComponentTest.java
index 48c3f4c..4213278 100644
--- a/components/camel-azure/camel-azure-storage-blob/src/test/java/org/apache/camel/component/azure/storage/blob/BlobComponentTest.java
+++ b/components/camel-azure/camel-azure-storage-blob/src/test/java/org/apache/camel/component/azure/storage/blob/BlobComponentTest.java
@@ -54,7 +54,7 @@ class BlobComponentTest extends CamelTestSupport {
     }
 
     @Test
-    void testCreateEndpointWithMinConfigForCredsOnly() throws Exception {
+    void testCreateEndpointWithMinConfigForCredsOnly() {
         context.getRegistry().bind("creds", storageSharedKeyCredential());
 
         final BlobEndpoint endpoint = (BlobEndpoint) context
@@ -110,7 +110,7 @@ class BlobComponentTest extends CamelTestSupport {
     }
 
     @Test
-    void testNoBlobNameProducerWithOpThatNeedsBlobName() throws Exception {
+    void testNoBlobNameProducerWithOpThatNeedsBlobName() {
         context.getRegistry().bind("creds", storageSharedKeyCredential());
 
         BlobEndpoint endpointWithOp = (BlobEndpoint) context.getEndpoint(
@@ -123,7 +123,7 @@ class BlobComponentTest extends CamelTestSupport {
     }
 
     @Test
-    void testHierarchicalBlobName() throws Exception {
+    void testHierarchicalBlobName() {
         context.getRegistry().bind("creds", storageSharedKeyCredential());
 
         BlobEndpoint endpoint = (BlobEndpoint) context
diff --git a/components/camel-azure/camel-azure-storage-blob/src/test/java/org/apache/camel/component/azure/storage/blob/integration/BlobChangeFeedOperationsIT.java b/components/camel-azure/camel-azure-storage-blob/src/test/java/org/apache/camel/component/azure/storage/blob/integration/BlobChangeFeedOperationsIT.java
index fa9bd42..22b7a5e 100644
--- a/components/camel-azure/camel-azure-storage-blob/src/test/java/org/apache/camel/component/azure/storage/blob/integration/BlobChangeFeedOperationsIT.java
+++ b/components/camel-azure/camel-azure-storage-blob/src/test/java/org/apache/camel/component/azure/storage/blob/integration/BlobChangeFeedOperationsIT.java
@@ -91,10 +91,10 @@ class BlobChangeFeedOperationsIT extends Base {
     }
 
     @Override
-    protected RouteBuilder createRouteBuilder() throws Exception {
+    protected RouteBuilder createRouteBuilder() {
         return new RouteBuilder() {
             @Override
-            public void configure() throws Exception {
+            public void configure() {
                 from("direct:getChangeFeed")
                         .to("azure-storage-blob://cameldev?operation=getChangeFeed")
                         .to(resultName);
diff --git a/components/camel-azure/camel-azure-storage-blob/src/test/java/org/apache/camel/component/azure/storage/blob/integration/BlobCopyProducerIt.java b/components/camel-azure/camel-azure-storage-blob/src/test/java/org/apache/camel/component/azure/storage/blob/integration/BlobCopyProducerIt.java
index ceccbc9..2c454ed 100644
--- a/components/camel-azure/camel-azure-storage-blob/src/test/java/org/apache/camel/component/azure/storage/blob/integration/BlobCopyProducerIt.java
+++ b/components/camel-azure/camel-azure-storage-blob/src/test/java/org/apache/camel/component/azure/storage/blob/integration/BlobCopyProducerIt.java
@@ -31,7 +31,7 @@ class BlobCopyProducerIt extends CamelTestSupport {
     private ProducerTemplate template;
 
     @Test
-    void testCopyBlob() throws InterruptedException {
+    void testCopyBlob() {
 
         template.send("direct:uploadBlockBlob", exchange -> {
             exchange.getIn().setHeader(BlobConstants.BLOB_NAME, "pmi.txt");
@@ -42,10 +42,10 @@ class BlobCopyProducerIt extends CamelTestSupport {
     }
 
     @Override
-    protected RouteBuilder createRouteBuilder() throws Exception {
+    protected RouteBuilder createRouteBuilder() {
         return new RouteBuilder() {
             @Override
-            public void configure() throws Exception {
+            public void configure() {
                 from("direct:copyBlob")
                         .to("azure-storage-blob://testblob214/test215?operation=copyBlob&sourceBlobAccessKey=RAW(sourceAccessKey)&accessKey=(accessKey)");
             }
diff --git a/components/camel-azure/camel-azure-storage-blob/src/test/java/org/apache/camel/component/azure/storage/blob/integration/BlobProducerIT.java b/components/camel-azure/camel-azure-storage-blob/src/test/java/org/apache/camel/component/azure/storage/blob/integration/BlobProducerIT.java
index 8ac562f..8f797de 100644
--- a/components/camel-azure/camel-azure-storage-blob/src/test/java/org/apache/camel/component/azure/storage/blob/integration/BlobProducerIT.java
+++ b/components/camel-azure/camel-azure-storage-blob/src/test/java/org/apache/camel/component/azure/storage/blob/integration/BlobProducerIT.java
@@ -17,7 +17,6 @@
 package org.apache.camel.component.azure.storage.blob.integration;
 
 import java.io.ByteArrayInputStream;
-import java.io.IOException;
 import java.io.InputStream;
 import java.nio.charset.StandardCharsets;
 import java.security.SecureRandom;
@@ -71,7 +70,7 @@ class BlobProducerIT extends Base {
     }
 
     @Test
-    void testCommitAndStageBlockBlob() throws InterruptedException, IOException {
+    void testCommitAndStageBlockBlob() throws InterruptedException {
         final String blobName = RandomStringUtils.randomAlphabetic(10);
 
         result.expectedMessageCount(1);
@@ -193,10 +192,10 @@ class BlobProducerIT extends Base {
     }
 
     @Override
-    protected RouteBuilder createRouteBuilder() throws Exception {
+    protected RouteBuilder createRouteBuilder() {
         return new RouteBuilder() {
             @Override
-            public void configure() throws Exception {
+            public void configure() {
                 from("direct:uploadBlockBlob")
                         .to(componentUri("uploadBlockBlob"))
                         .to(resultName);

[camel] 03/06: CAMEL-17763: cleaned up unused exceptions in camel-azure-servicebus

Posted by or...@apache.org.
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

commit 5564bcda46cdf47386df9c35cf9df0f6275067dc
Author: Otavio Rodolfo Piske <an...@gmail.com>
AuthorDate: Tue Mar 8 13:50:23 2022 +0100

    CAMEL-17763: cleaned up unused exceptions in camel-azure-servicebus
---
 .../camel/component/azure/servicebus/ServiceBusEndpointTest.java      | 2 +-
 .../azure/servicebus/integration/ServiceBusConsumerTest.java          | 4 ++--
 .../azure/servicebus/integration/ServiceBusProducerTest.java          | 4 ++--
 3 files changed, 5 insertions(+), 5 deletions(-)

diff --git a/components/camel-azure/camel-azure-servicebus/src/test/java/org/apache/camel/component/azure/servicebus/ServiceBusEndpointTest.java b/components/camel-azure/camel-azure-servicebus/src/test/java/org/apache/camel/component/azure/servicebus/ServiceBusEndpointTest.java
index 6b03785..820d7217 100644
--- a/components/camel-azure/camel-azure-servicebus/src/test/java/org/apache/camel/component/azure/servicebus/ServiceBusEndpointTest.java
+++ b/components/camel-azure/camel-azure-servicebus/src/test/java/org/apache/camel/component/azure/servicebus/ServiceBusEndpointTest.java
@@ -32,7 +32,7 @@ import static org.junit.jupiter.api.Assertions.assertThrows;
 class ServiceBusEndpointTest extends CamelTestSupport {
 
     @Test
-    void testCreateWithInvalidData() throws Exception {
+    void testCreateWithInvalidData() {
         assertThrows(ResolveEndpointFailedException.class,
                 () -> context.getEndpoint("azure-servicebus:test//?"));
 
diff --git a/components/camel-azure/camel-azure-servicebus/src/test/java/org/apache/camel/component/azure/servicebus/integration/ServiceBusConsumerTest.java b/components/camel-azure/camel-azure-servicebus/src/test/java/org/apache/camel/component/azure/servicebus/integration/ServiceBusConsumerTest.java
index 531412e..c3cc14b 100644
--- a/components/camel-azure/camel-azure-servicebus/src/test/java/org/apache/camel/component/azure/servicebus/integration/ServiceBusConsumerTest.java
+++ b/components/camel-azure/camel-azure-servicebus/src/test/java/org/apache/camel/component/azure/servicebus/integration/ServiceBusConsumerTest.java
@@ -102,10 +102,10 @@ class ServiceBusConsumerTest extends BaseCamelServiceBusTestSupport {
     }
 
     @Override
-    protected RouteBuilder createRouteBuilder() throws Exception {
+    protected RouteBuilder createRouteBuilder() {
         return new RouteBuilder() {
             @Override
-            public void configure() throws Exception {
+            public void configure() {
                 from("azure-servicebus:test//?connectionString=test").to(receiveMessagesResult);
                 from("azure-servicebus:test//?connectionString=test&consumerOperation=peekMessages&peekNumMaxMessages=3")
                         .to(peekMessagesResult);
diff --git a/components/camel-azure/camel-azure-servicebus/src/test/java/org/apache/camel/component/azure/servicebus/integration/ServiceBusProducerTest.java b/components/camel-azure/camel-azure-servicebus/src/test/java/org/apache/camel/component/azure/servicebus/integration/ServiceBusProducerTest.java
index b63df97..55631c6 100644
--- a/components/camel-azure/camel-azure-servicebus/src/test/java/org/apache/camel/component/azure/servicebus/integration/ServiceBusProducerTest.java
+++ b/components/camel-azure/camel-azure-servicebus/src/test/java/org/apache/camel/component/azure/servicebus/integration/ServiceBusProducerTest.java
@@ -156,10 +156,10 @@ class ServiceBusProducerTest extends BaseCamelServiceBusTestSupport {
     }
 
     @Override
-    protected RouteBuilder createRouteBuilder() throws Exception {
+    protected RouteBuilder createRouteBuilder() {
         return new RouteBuilder() {
             @Override
-            public void configure() throws Exception {
+            public void configure() {
                 from("direct:sendBatchMessages").to("azure-servicebus:test//?connectionString=test").to(result);
                 from("direct:sendMessage").to("azure-servicebus:test//?connectionString=test").to(result);
                 from("direct:scheduleMessage")

[camel] 06/06: CAMEL-17763: cleaned up unused exceptions in camel-azure-storage-queue

Posted by or...@apache.org.
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

commit ed4107adcd807e70e84cdb44a0ff73431fafa1cf
Author: Otavio Rodolfo Piske <an...@gmail.com>
AuthorDate: Tue Mar 8 13:50:23 2022 +0100

    CAMEL-17763: cleaned up unused exceptions in camel-azure-storage-queue
---
 .../camel/component/azure/storage/queue/QueueComponentTest.java     | 2 +-
 .../apache/camel/component/azure/storage/queue/QueueTestUtils.java  | 2 +-
 .../azure/storage/queue/integration/StorageQueueConsumerIT.java     | 4 ++--
 .../azure/storage/queue/integration/StorageQueueProducerIT.java     | 6 +++---
 4 files changed, 7 insertions(+), 7 deletions(-)

diff --git a/components/camel-azure/camel-azure-storage-queue/src/test/java/org/apache/camel/component/azure/storage/queue/QueueComponentTest.java b/components/camel-azure/camel-azure-storage-queue/src/test/java/org/apache/camel/component/azure/storage/queue/QueueComponentTest.java
index b5a3334..544a3db 100644
--- a/components/camel-azure/camel-azure-storage-queue/src/test/java/org/apache/camel/component/azure/storage/queue/QueueComponentTest.java
+++ b/components/camel-azure/camel-azure-storage-queue/src/test/java/org/apache/camel/component/azure/storage/queue/QueueComponentTest.java
@@ -52,7 +52,7 @@ class QueueComponentTest extends CamelTestSupport {
     }
 
     @Test
-    public void testCreateEndpointWithMinConfigForCredsOnly() throws Exception {
+    public void testCreateEndpointWithMinConfigForCredsOnly() {
         context.getRegistry().bind("creds", new StorageSharedKeyCredential("fake", "fake"));
 
         final QueueEndpoint endpoint
diff --git a/components/camel-azure/camel-azure-storage-queue/src/test/java/org/apache/camel/component/azure/storage/queue/QueueTestUtils.java b/components/camel-azure/camel-azure-storage-queue/src/test/java/org/apache/camel/component/azure/storage/queue/QueueTestUtils.java
index ec5cb59..dd042a7 100644
--- a/components/camel-azure/camel-azure-storage-queue/src/test/java/org/apache/camel/component/azure/storage/queue/QueueTestUtils.java
+++ b/components/camel-azure/camel-azure-storage-queue/src/test/java/org/apache/camel/component/azure/storage/queue/QueueTestUtils.java
@@ -40,7 +40,7 @@ public final class QueueTestUtils {
         return properties;
     }
 
-    public static Properties loadAzureAccessFromJvmEnv() throws Exception {
+    public static Properties loadAzureAccessFromJvmEnv() {
         final Properties properties = new Properties();
         if (System.getProperty("accountName") == null || System.getProperty("accessKey") == null) {
             fail("Make sure to supply azure accessKey or accountName, e.g:  mvn verify -PfullTests -DaccountName=myacc -DaccessKey=mykey");
diff --git a/components/camel-azure/camel-azure-storage-queue/src/test/java/org/apache/camel/component/azure/storage/queue/integration/StorageQueueConsumerIT.java b/components/camel-azure/camel-azure-storage-queue/src/test/java/org/apache/camel/component/azure/storage/queue/integration/StorageQueueConsumerIT.java
index 9634fe1..2b427ad 100644
--- a/components/camel-azure/camel-azure-storage-queue/src/test/java/org/apache/camel/component/azure/storage/queue/integration/StorageQueueConsumerIT.java
+++ b/components/camel-azure/camel-azure-storage-queue/src/test/java/org/apache/camel/component/azure/storage/queue/integration/StorageQueueConsumerIT.java
@@ -58,10 +58,10 @@ class StorageQueueConsumerIT extends StorageQueueBase {
     }
 
     @Override
-    protected RouteBuilder createRouteBuilder() throws Exception {
+    protected RouteBuilder createRouteBuilder() {
         return new RouteBuilder() {
             @Override
-            public void configure() throws Exception {
+            public void configure() {
                 from("azure-storage-queue://cameldev/" + queueName + "?maxMessages=5")
                         .to(resultName);
 
diff --git a/components/camel-azure/camel-azure-storage-queue/src/test/java/org/apache/camel/component/azure/storage/queue/integration/StorageQueueProducerIT.java b/components/camel-azure/camel-azure-storage-queue/src/test/java/org/apache/camel/component/azure/storage/queue/integration/StorageQueueProducerIT.java
index fa5db08..e752a8e 100644
--- a/components/camel-azure/camel-azure-storage-queue/src/test/java/org/apache/camel/component/azure/storage/queue/integration/StorageQueueProducerIT.java
+++ b/components/camel-azure/camel-azure-storage-queue/src/test/java/org/apache/camel/component/azure/storage/queue/integration/StorageQueueProducerIT.java
@@ -101,10 +101,10 @@ class StorageQueueProducerIT extends StorageQueueBase {
     }
 
     @Override
-    protected RouteBuilder createRouteBuilder() throws Exception {
+    protected RouteBuilder createRouteBuilder() {
         return new RouteBuilder() {
             @Override
-            public void configure() throws Exception {
+            public void configure() {
                 from("direct:createQueue")
                         .to(componentUri("createQueue", "testqueue"))
                         .to(resultName);
@@ -129,7 +129,7 @@ class StorageQueueProducerIT extends StorageQueueBase {
     }
 
     @Test
-    public void testHeaderPreservation() throws InterruptedException {
+    public void testHeaderPreservation() {
 
         // first test if queue is not created
         template.send("direct:sendMessage", ExchangePattern.InOnly, exchange -> {